package context

Import Path
	context (on golang.org and go.dev)

Dependency Relation
	imports 5 packages, and imported by 153 packages

Involved Source Files Package context defines the Context type, which carries deadlines, cancellation signals, and other request-scoped values across API boundaries and between processes. Incoming requests to a server should create a Context, and outgoing calls to servers should accept a Context. The chain of function calls between them must propagate the Context, optionally replacing it with a derived Context created using WithCancel, WithDeadline, WithTimeout, or WithValue. When a Context is canceled, all Contexts derived from it are also canceled. The WithCancel, WithDeadline, and WithTimeout functions take a Context (the parent) and return a derived Context (the child) and a CancelFunc. Calling the CancelFunc cancels the child and its children, removes the parent's reference to the child, and stops any associated timers. Failing to call the CancelFunc leaks the child and its children until the parent is canceled or the timer fires. The go vet tool checks that CancelFuncs are used on all control-flow paths. Programs that use Contexts should follow these rules to keep interfaces consistent across packages and enable static analysis tools to check context propagation: Do not store Contexts inside a struct type; instead, pass a Context explicitly to each function that needs it. The Context should be the first parameter, typically named ctx: func DoSomething(ctx context.Context, arg Arg) error { // ... use ctx ... } Do not pass a nil Context, even if a function permits it. Pass context.TODO if you are unsure about which Context to use. Use context Values only for request-scoped data that transits processes and APIs, not for passing optional parameters to functions. The same Context may be passed to functions running in different goroutines; Contexts are safe for simultaneous use by multiple goroutines. See https://blog.golang.org/context for example code for a server that uses Contexts.
Code Examples package main import ( "context" "fmt" ) func main() { // gen generates integers in a separate goroutine and // sends them to the returned channel. // The callers of gen need to cancel the context once // they are done consuming generated integers not to leak // the internal goroutine started by gen. gen := func(ctx context.Context) <-chan int { dst := make(chan int) n := 1 go func() { for { select { case <-ctx.Done(): return // returning not to leak the goroutine case dst <- n: n++ } } }() return dst } ctx, cancel := context.WithCancel(context.Background()) defer cancel() // cancel when we are finished consuming integers for n := range gen(ctx) { fmt.Println(n) if n == 5 { break } } } package main import ( "context" "fmt" "time" ) const shortDuration = 1 * time.Millisecond func main() { d := time.Now().Add(shortDuration) ctx, cancel := context.WithDeadline(context.Background(), d) // Even though ctx will be expired, it is good practice to call its // cancellation function in any case. Failure to do so may keep the // context and its parent alive longer than necessary. defer cancel() select { case <-time.After(1 * time.Second): fmt.Println("overslept") case <-ctx.Done(): fmt.Println(ctx.Err()) } } package main import ( "context" "fmt" "time" ) const shortDuration = 1 * time.Millisecond func main() { // Pass a context with a timeout to tell a blocking function that it // should abandon its work after the timeout elapses. ctx, cancel := context.WithTimeout(context.Background(), shortDuration) defer cancel() select { case <-time.After(1 * time.Second): fmt.Println("overslept") case <-ctx.Done(): fmt.Println(ctx.Err()) // prints "context deadline exceeded" } } package main import ( "context" "fmt" ) func main() { type favContextKey string f := func(ctx context.Context, k favContextKey) { if v := ctx.Value(k); v != nil { fmt.Println("found value:", v) return } fmt.Println("key not found:", k) } k := favContextKey("language") ctx := context.WithValue(context.Background(), k, "Go") f(ctx, k) f(ctx, favContextKey("color")) }
Package-Level Type Names (total 9, in which 2 are exported)
/* sort exporteds by: | */
A CancelFunc tells an operation to abandon its work. A CancelFunc does not wait for the work to stop. A CancelFunc may be called by multiple goroutines simultaneously. After the first call, subsequent calls to a CancelFunc do nothing. func WithCancel(parent Context) (ctx Context, cancel CancelFunc) func WithDeadline(parent Context, d time.Time) (Context, CancelFunc) func WithTimeout(parent Context, timeout time.Duration) (Context, CancelFunc) func golang.org/x/net/context.WithCancel(parent context.Context) (ctx context.Context, cancel context.CancelFunc) func golang.org/x/net/context.WithDeadline(parent context.Context, deadline time.Time) (context.Context, context.CancelFunc) func golang.org/x/net/context.WithTimeout(parent context.Context, timeout time.Duration) (context.Context, context.CancelFunc)
A Context carries a deadline, a cancellation signal, and other values across API boundaries. Context's methods may be called by multiple goroutines simultaneously. Deadline returns the time when work done on behalf of this context should be canceled. Deadline returns ok==false when no deadline is set. Successive calls to Deadline return the same results. Done returns a channel that's closed when work done on behalf of this context should be canceled. Done may return nil if this context can never be canceled. Successive calls to Done return the same value. The close of the Done channel may happen asynchronously, after the cancel function returns. WithCancel arranges for Done to be closed when cancel is called; WithDeadline arranges for Done to be closed when the deadline expires; WithTimeout arranges for Done to be closed when the timeout elapses. Done is provided for use in select statements: // Stream generates values with DoSomething and sends them to out // until DoSomething returns an error or ctx.Done is closed. func Stream(ctx context.Context, out chan<- Value) error { for { v, err := DoSomething(ctx) if err != nil { return err } select { case <-ctx.Done(): return ctx.Err() case out <- v: } } } See https://blog.golang.org/pipelines for more examples of how to use a Done channel for cancellation. If Done is not yet closed, Err returns nil. If Done is closed, Err returns a non-nil error explaining why: Canceled if the context was canceled or DeadlineExceeded if the context's deadline passed. After Err returns a non-nil error, successive calls to Err return the same error. Value returns the value associated with this context for key, or nil if no value is associated with key. Successive calls to Value with the same key returns the same result. Use context values only for request-scoped data that transits processes and API boundaries, not for passing optional parameters to functions. A key identifies a specific value in a Context. Functions that wish to store values in Context typically allocate a key in a global variable then use that key as the argument to context.WithValue and Context.Value. A key can be any type that supports equality; packages should define keys as an unexported type to avoid collisions. Packages that define a Context key should provide type-safe accessors for the values stored using that key: // Package user defines a User type that's stored in Contexts. package user import "context" // User is the type of value stored in the Contexts. type User struct {...} // key is an unexported type for keys defined in this package. // This prevents collisions with keys defined in other packages. type key int // userKey is the key for user.User values in Contexts. It is // unexported; clients use user.NewContext and user.FromContext // instead of using this key directly. var userKey key // NewContext returns a new Context that carries value u. func NewContext(ctx context.Context, u *User) context.Context { return context.WithValue(ctx, userKey, u) } // FromContext returns the User value stored in ctx, if any. func FromContext(ctx context.Context) (*User, bool) { u, ok := ctx.Value(userKey).(*User) return u, ok } func Background() Context func TODO() Context func WithCancel(parent Context) (ctx Context, cancel CancelFunc) func WithDeadline(parent Context, d time.Time) (Context, CancelFunc) func WithTimeout(parent Context, timeout time.Duration) (Context, CancelFunc) func WithValue(parent Context, key, val interface{}) Context func cloud.google.com/go/internal/trace.StartSpan(ctx Context, name string) Context func github.com/aws/aws-sdk-go/aws.BackgroundContext() aws.Context func github.com/aws/aws-sdk-go/aws/request.(*Request).Context() aws.Context func github.com/go-redis/redis/v8.(*Client).Context() Context func github.com/go-redis/redis/v8.(*ClusterClient).Context() Context func github.com/go-redis/redis/v8.Hook.BeforeProcess(ctx Context, cmd redis.Cmder) (Context, error) func github.com/go-redis/redis/v8.Hook.BeforeProcessPipeline(ctx Context, cmds []redis.Cmder) (Context, error) func github.com/go-redis/redis/v8.(*Ring).Context() Context func github.com/go-redis/redis/v8.(*SentinelClient).Context() Context func github.com/go-redis/redis/v8.(*Tx).Context() Context func github.com/go-redis/redis/v8.UniversalClient.Context() Context func go.opencensus.io/plugin/ocgrpc.(*ClientHandler).TagConn(ctx Context, cti *stats.ConnTagInfo) Context func go.opencensus.io/plugin/ocgrpc.(*ClientHandler).TagRPC(ctx Context, rti *stats.RPCTagInfo) Context func go.opencensus.io/plugin/ocgrpc.(*ServerHandler).TagConn(ctx Context, cti *stats.ConnTagInfo) Context func go.opencensus.io/plugin/ocgrpc.(*ServerHandler).TagRPC(ctx Context, rti *stats.RPCTagInfo) Context func go.opencensus.io/tag.New(ctx Context, mutator ...tag.Mutator) (Context, error) func go.opencensus.io/tag.NewContext(ctx Context, m *tag.Map) Context func go.opencensus.io/trace.NewContext(parent Context, s *trace.Span) Context func go.opencensus.io/trace.StartSpan(ctx Context, name string, o ...trace.StartOption) (Context, *trace.Span) func go.opencensus.io/trace.StartSpanWithRemoteParent(ctx Context, name string, parent trace.SpanContext, o ...trace.StartOption) (Context, *trace.Span) func go.opentelemetry.io/otel.Tracer.Start(ctx Context, spanName string, opts ...trace.StartOption) (Context, trace.Span) func go.opentelemetry.io/otel/api/correlation.ContextWithGetHook(ctx Context, hook correlation.GetHookFunc) Context func go.opentelemetry.io/otel/api/correlation.ContextWithMap(ctx Context, m correlation.Map) Context func go.opentelemetry.io/otel/api/correlation.ContextWithNoHooks(ctx Context) (Context, correlation.SetHookFunc, correlation.GetHookFunc) func go.opentelemetry.io/otel/api/correlation.ContextWithSetHook(ctx Context, hook correlation.SetHookFunc) Context func go.opentelemetry.io/otel/api/correlation.NewContext(ctx Context, keyvalues ...label.KeyValue) Context func go.opentelemetry.io/otel/api/correlation.CorrelationContext.Extract(ctx Context, supplier propagation.HTTPSupplier) Context func go.opentelemetry.io/otel/api/propagation.ExtractHTTP(ctx Context, props propagation.Propagators, supplier propagation.HTTPSupplier) Context func go.opentelemetry.io/otel/api/propagation.HTTPExtractor.Extract(Context, propagation.HTTPSupplier) Context func go.opentelemetry.io/otel/api/propagation.HTTPPropagator.Extract(Context, propagation.HTTPSupplier) Context func go.opentelemetry.io/otel/api/trace.ContextWithRemoteSpanContext(ctx Context, sc trace.SpanContext) Context func go.opentelemetry.io/otel/api/trace.ContextWithSpan(ctx Context, span trace.Span) Context func go.opentelemetry.io/otel/api/trace.B3.Extract(ctx Context, supplier propagation.HTTPSupplier) Context func go.opentelemetry.io/otel/api/trace.NoopTracer.Start(ctx Context, name string, opts ...trace.StartOption) (Context, trace.Span) func go.opentelemetry.io/otel/api/trace.TraceContext.Extract(ctx Context, supplier propagation.HTTPSupplier) Context func go.opentelemetry.io/otel/api/trace.Tracer.Start(ctx Context, spanName string, opts ...trace.StartOption) (Context, trace.Span) func golang.org/x/net/context.Background() context.Context func golang.org/x/net/context.TODO() context.Context func golang.org/x/net/context.WithCancel(parent context.Context) (ctx context.Context, cancel context.CancelFunc) func golang.org/x/net/context.WithDeadline(parent context.Context, deadline time.Time) (context.Context, context.CancelFunc) func golang.org/x/net/context.WithTimeout(parent context.Context, timeout time.Duration) (context.Context, context.CancelFunc) func golang.org/x/net/context.WithValue(parent context.Context, key interface{}, val interface{}) context.Context func golang.org/x/net/trace.NewContext(ctx Context, tr trace.Trace) Context func golang.org/x/pkgsite/internal/experiment.NewContext(ctx Context, experimentNames ...string) Context func golang.org/x/pkgsite/internal/log.NewContextWithLabel(ctx Context, key, value string) Context func golang.org/x/pkgsite/internal/log.NewContextWithTraceID(ctx Context, traceID string) Context func golang.org/x/pkgsite/internal/xcontext.Detach(ctx Context) Context func golang.org/x/sync/errgroup.WithContext(ctx Context) (*errgroup.Group, Context) func google.golang.org/grpc.NewContextWithServerTransportStream(ctx Context, stream grpc.ServerTransportStream) Context func google.golang.org/grpc.ClientStream.Context() Context func google.golang.org/grpc.ServerStream.Context() Context func google.golang.org/grpc.Stream.Context() Context func google.golang.org/grpc/balancer/grpclb/grpc_lb_v1.LoadBalancer_BalanceLoadClient.Context() Context func google.golang.org/grpc/balancer/grpclb/grpc_lb_v1.LoadBalancer_BalanceLoadServer.Context() Context func google.golang.org/grpc/credentials/alts/internal/proto/grpc_gcp.HandshakerService_DoHandshakeClient.Context() Context func google.golang.org/grpc/credentials/alts/internal/proto/grpc_gcp.HandshakerService_DoHandshakeServer.Context() Context func google.golang.org/grpc/internal/grpcutil.WithExtraMetadata(ctx Context, md metadata.MD) Context func google.golang.org/grpc/internal/transport.(*Stream).Context() Context func google.golang.org/grpc/metadata.AppendToOutgoingContext(ctx Context, kv ...string) Context func google.golang.org/grpc/metadata.NewIncomingContext(ctx Context, md metadata.MD) Context func google.golang.org/grpc/metadata.NewOutgoingContext(ctx Context, md metadata.MD) Context func google.golang.org/grpc/peer.NewContext(ctx Context, p *peer.Peer) Context func google.golang.org/grpc/stats.SetIncomingTags(ctx Context, b []byte) Context func google.golang.org/grpc/stats.SetIncomingTrace(ctx Context, b []byte) Context func google.golang.org/grpc/stats.SetTags(ctx Context, b []byte) Context func google.golang.org/grpc/stats.SetTrace(ctx Context, b []byte) Context func google.golang.org/grpc/stats.Handler.TagConn(Context, *stats.ConnTagInfo) Context func google.golang.org/grpc/stats.Handler.TagRPC(Context, *stats.RPCTagInfo) Context func net/http.(*Request).Context() Context func net/http/httptrace.WithClientTrace(ctx Context, trace *httptrace.ClientTrace) Context func runtime/pprof.WithLabels(ctx Context, labels pprof.LabelSet) Context func runtime/trace.NewTask(pctx Context, taskType string) (ctx Context, task *trace.Task) func WithCancel(parent Context) (ctx Context, cancel CancelFunc) func WithDeadline(parent Context, d time.Time) (Context, CancelFunc) func WithTimeout(parent Context, timeout time.Duration) (Context, CancelFunc) func WithValue(parent Context, key, val interface{}) Context func cloud.google.com/go/cloudtasks/apiv2.NewClient(ctx Context, opts ...option.ClientOption) (*cloudtasks.Client, error) func cloud.google.com/go/cloudtasks/apiv2.(*Client).CreateQueue(ctx Context, req *taskspb.CreateQueueRequest, opts ...gax.CallOption) (*taskspb.Queue, error) func cloud.google.com/go/cloudtasks/apiv2.(*Client).CreateTask(ctx Context, req *taskspb.CreateTaskRequest, opts ...gax.CallOption) (*taskspb.Task, error) func cloud.google.com/go/cloudtasks/apiv2.(*Client).DeleteQueue(ctx Context, req *taskspb.DeleteQueueRequest, opts ...gax.CallOption) error func cloud.google.com/go/cloudtasks/apiv2.(*Client).DeleteTask(ctx Context, req *taskspb.DeleteTaskRequest, opts ...gax.CallOption) error func cloud.google.com/go/cloudtasks/apiv2.(*Client).GetIamPolicy(ctx Context, req *iampb.GetIamPolicyRequest, opts ...gax.CallOption) (*iampb.Policy, error) func cloud.google.com/go/cloudtasks/apiv2.(*Client).GetQueue(ctx Context, req *taskspb.GetQueueRequest, opts ...gax.CallOption) (*taskspb.Queue, error) func cloud.google.com/go/cloudtasks/apiv2.(*Client).GetTask(ctx Context, req *taskspb.GetTaskRequest, opts ...gax.CallOption) (*taskspb.Task, error) func cloud.google.com/go/cloudtasks/apiv2.(*Client).ListQueues(ctx Context, req *taskspb.ListQueuesRequest, opts ...gax.CallOption) *cloudtasks.QueueIterator func cloud.google.com/go/cloudtasks/apiv2.(*Client).ListTasks(ctx Context, req *taskspb.ListTasksRequest, opts ...gax.CallOption) *cloudtasks.TaskIterator func cloud.google.com/go/cloudtasks/apiv2.(*Client).PauseQueue(ctx Context, req *taskspb.PauseQueueRequest, opts ...gax.CallOption) (*taskspb.Queue, error) func cloud.google.com/go/cloudtasks/apiv2.(*Client).PurgeQueue(ctx Context, req *taskspb.PurgeQueueRequest, opts ...gax.CallOption) (*taskspb.Queue, error) func cloud.google.com/go/cloudtasks/apiv2.(*Client).ResumeQueue(ctx Context, req *taskspb.ResumeQueueRequest, opts ...gax.CallOption) (*taskspb.Queue, error) func cloud.google.com/go/cloudtasks/apiv2.(*Client).RunTask(ctx Context, req *taskspb.RunTaskRequest, opts ...gax.CallOption) (*taskspb.Task, error) func cloud.google.com/go/cloudtasks/apiv2.(*Client).SetIamPolicy(ctx Context, req *iampb.SetIamPolicyRequest, opts ...gax.CallOption) (*iampb.Policy, error) func cloud.google.com/go/cloudtasks/apiv2.(*Client).TestIamPermissions(ctx Context, req *iampb.TestIamPermissionsRequest, opts ...gax.CallOption) (*iampb.TestIamPermissionsResponse, error) func cloud.google.com/go/cloudtasks/apiv2.(*Client).UpdateQueue(ctx Context, req *taskspb.UpdateQueueRequest, opts ...gax.CallOption) (*taskspb.Queue, error) func cloud.google.com/go/container/apiv1.NewClusterManagerClient(ctx Context, opts ...option.ClientOption) (*container.ClusterManagerClient, error) func cloud.google.com/go/container/apiv1.(*ClusterManagerClient).CancelOperation(ctx Context, req *containerpb.CancelOperationRequest, opts ...gax.CallOption) error func cloud.google.com/go/container/apiv1.(*ClusterManagerClient).CompleteIPRotation(ctx Context, req *containerpb.CompleteIPRotationRequest, opts ...gax.CallOption) (*containerpb.Operation, error) func cloud.google.com/go/container/apiv1.(*ClusterManagerClient).CreateCluster(ctx Context, req *containerpb.CreateClusterRequest, opts ...gax.CallOption) (*containerpb.Operation, error) func cloud.google.com/go/container/apiv1.(*ClusterManagerClient).CreateNodePool(ctx Context, req *containerpb.CreateNodePoolRequest, opts ...gax.CallOption) (*containerpb.Operation, error) func cloud.google.com/go/container/apiv1.(*ClusterManagerClient).DeleteCluster(ctx Context, req *containerpb.DeleteClusterRequest, opts ...gax.CallOption) (*containerpb.Operation, error) func cloud.google.com/go/container/apiv1.(*ClusterManagerClient).DeleteNodePool(ctx Context, req *containerpb.DeleteNodePoolRequest, opts ...gax.CallOption) (*containerpb.Operation, error) func cloud.google.com/go/container/apiv1.(*ClusterManagerClient).GetCluster(ctx Context, req *containerpb.GetClusterRequest, opts ...gax.CallOption) (*containerpb.Cluster, error) func cloud.google.com/go/container/apiv1.(*ClusterManagerClient).GetNodePool(ctx Context, req *containerpb.GetNodePoolRequest, opts ...gax.CallOption) (*containerpb.NodePool, error) func cloud.google.com/go/container/apiv1.(*ClusterManagerClient).GetOperation(ctx Context, req *containerpb.GetOperationRequest, opts ...gax.CallOption) (*containerpb.Operation, error) func cloud.google.com/go/container/apiv1.(*ClusterManagerClient).GetServerConfig(ctx Context, req *containerpb.GetServerConfigRequest, opts ...gax.CallOption) (*containerpb.ServerConfig, error) func cloud.google.com/go/container/apiv1.(*ClusterManagerClient).ListClusters(ctx Context, req *containerpb.ListClustersRequest, opts ...gax.CallOption) (*containerpb.ListClustersResponse, error) func cloud.google.com/go/container/apiv1.(*ClusterManagerClient).ListNodePools(ctx Context, req *containerpb.ListNodePoolsRequest, opts ...gax.CallOption) (*containerpb.ListNodePoolsResponse, error) func cloud.google.com/go/container/apiv1.(*ClusterManagerClient).ListOperations(ctx Context, req *containerpb.ListOperationsRequest, opts ...gax.CallOption) (*containerpb.ListOperationsResponse, error) func cloud.google.com/go/container/apiv1.(*ClusterManagerClient).ListUsableSubnetworks(ctx Context, req *containerpb.ListUsableSubnetworksRequest, opts ...gax.CallOption) *container.UsableSubnetworkIterator func cloud.google.com/go/container/apiv1.(*ClusterManagerClient).RollbackNodePoolUpgrade(ctx Context, req *containerpb.RollbackNodePoolUpgradeRequest, opts ...gax.CallOption) (*containerpb.Operation, error) func cloud.google.com/go/container/apiv1.(*ClusterManagerClient).SetAddonsConfig(ctx Context, req *containerpb.SetAddonsConfigRequest, opts ...gax.CallOption) (*containerpb.Operation, error) func cloud.google.com/go/container/apiv1.(*ClusterManagerClient).SetLabels(ctx Context, req *containerpb.SetLabelsRequest, opts ...gax.CallOption) (*containerpb.Operation, error) func cloud.google.com/go/container/apiv1.(*ClusterManagerClient).SetLegacyAbac(ctx Context, req *containerpb.SetLegacyAbacRequest, opts ...gax.CallOption) (*containerpb.Operation, error) func cloud.google.com/go/container/apiv1.(*ClusterManagerClient).SetLocations(ctx Context, req *containerpb.SetLocationsRequest, opts ...gax.CallOption) (*containerpb.Operation, error) func cloud.google.com/go/container/apiv1.(*ClusterManagerClient).SetLoggingService(ctx Context, req *containerpb.SetLoggingServiceRequest, opts ...gax.CallOption) (*containerpb.Operation, error) func cloud.google.com/go/container/apiv1.(*ClusterManagerClient).SetMaintenancePolicy(ctx Context, req *containerpb.SetMaintenancePolicyRequest, opts ...gax.CallOption) (*containerpb.Operation, error) func cloud.google.com/go/container/apiv1.(*ClusterManagerClient).SetMasterAuth(ctx Context, req *containerpb.SetMasterAuthRequest, opts ...gax.CallOption) (*containerpb.Operation, error) func cloud.google.com/go/container/apiv1.(*ClusterManagerClient).SetMonitoringService(ctx Context, req *containerpb.SetMonitoringServiceRequest, opts ...gax.CallOption) (*containerpb.Operation, error) func cloud.google.com/go/container/apiv1.(*ClusterManagerClient).SetNetworkPolicy(ctx Context, req *containerpb.SetNetworkPolicyRequest, opts ...gax.CallOption) (*containerpb.Operation, error) func cloud.google.com/go/container/apiv1.(*ClusterManagerClient).SetNodePoolAutoscaling(ctx Context, req *containerpb.SetNodePoolAutoscalingRequest, opts ...gax.CallOption) (*containerpb.Operation, error) func cloud.google.com/go/container/apiv1.(*ClusterManagerClient).SetNodePoolManagement(ctx Context, req *containerpb.SetNodePoolManagementRequest, opts ...gax.CallOption) (*containerpb.Operation, error) func cloud.google.com/go/container/apiv1.(*ClusterManagerClient).SetNodePoolSize(ctx Context, req *containerpb.SetNodePoolSizeRequest, opts ...gax.CallOption) (*containerpb.Operation, error) func cloud.google.com/go/container/apiv1.(*ClusterManagerClient).StartIPRotation(ctx Context, req *containerpb.StartIPRotationRequest, opts ...gax.CallOption) (*containerpb.Operation, error) func cloud.google.com/go/container/apiv1.(*ClusterManagerClient).UpdateCluster(ctx Context, req *containerpb.UpdateClusterRequest, opts ...gax.CallOption) (*containerpb.Operation, error) func cloud.google.com/go/container/apiv1.(*ClusterManagerClient).UpdateMaster(ctx Context, req *containerpb.UpdateMasterRequest, opts ...gax.CallOption) (*containerpb.Operation, error) func cloud.google.com/go/container/apiv1.(*ClusterManagerClient).UpdateNodePool(ctx Context, req *containerpb.UpdateNodePoolRequest, opts ...gax.CallOption) (*containerpb.Operation, error) func cloud.google.com/go/errorreporting.NewClient(ctx Context, projectID string, cfg errorreporting.Config, opts ...option.ClientOption) (*errorreporting.Client, error) func cloud.google.com/go/errorreporting.(*Client).ReportSync(ctx Context, e errorreporting.Entry) error func cloud.google.com/go/errorreporting/apiv1beta1.NewErrorGroupClient(ctx Context, opts ...option.ClientOption) (*errorreporting.ErrorGroupClient, error) func cloud.google.com/go/errorreporting/apiv1beta1.NewErrorStatsClient(ctx Context, opts ...option.ClientOption) (*errorreporting.ErrorStatsClient, error) func cloud.google.com/go/errorreporting/apiv1beta1.NewReportErrorsClient(ctx Context, opts ...option.ClientOption) (*errorreporting.ReportErrorsClient, error) func cloud.google.com/go/errorreporting/apiv1beta1.(*ErrorGroupClient).GetGroup(ctx Context, req *clouderrorreportingpb.GetGroupRequest, opts ...gax.CallOption) (*clouderrorreportingpb.ErrorGroup, error) func cloud.google.com/go/errorreporting/apiv1beta1.(*ErrorGroupClient).UpdateGroup(ctx Context, req *clouderrorreportingpb.UpdateGroupRequest, opts ...gax.CallOption) (*clouderrorreportingpb.ErrorGroup, error) func cloud.google.com/go/errorreporting/apiv1beta1.(*ErrorStatsClient).DeleteEvents(ctx Context, req *clouderrorreportingpb.DeleteEventsRequest, opts ...gax.CallOption) (*clouderrorreportingpb.DeleteEventsResponse, error) func cloud.google.com/go/errorreporting/apiv1beta1.(*ErrorStatsClient).ListEvents(ctx Context, req *clouderrorreportingpb.ListEventsRequest, opts ...gax.CallOption) *errorreporting.ErrorEventIterator func cloud.google.com/go/errorreporting/apiv1beta1.(*ErrorStatsClient).ListGroupStats(ctx Context, req *clouderrorreportingpb.ListGroupStatsRequest, opts ...gax.CallOption) *errorreporting.ErrorGroupStatsIterator func cloud.google.com/go/errorreporting/apiv1beta1.(*ReportErrorsClient).ReportErrorEvent(ctx Context, req *clouderrorreportingpb.ReportErrorEventRequest, opts ...gax.CallOption) (*clouderrorreportingpb.ReportErrorEventResponse, error) func cloud.google.com/go/iam.(*Handle).Policy(ctx Context) (*iam.Policy, error) func cloud.google.com/go/iam.(*Handle).SetPolicy(ctx Context, policy *iam.Policy) error func cloud.google.com/go/iam.(*Handle).TestPermissions(ctx Context, permissions []string) ([]string, error) func cloud.google.com/go/iam.(*Handle3).Policy(ctx Context) (*iam.Policy3, error) func cloud.google.com/go/iam.(*Handle3).SetPolicy(ctx Context, policy *iam.Policy3) error func cloud.google.com/go/iam.(*Handle3).TestPermissions(ctx Context, permissions []string) ([]string, error) func cloud.google.com/go/internal.Retry(ctx Context, bo gax.Backoff, f func() (stop bool, err error)) error func cloud.google.com/go/internal/trace.EndSpan(ctx Context, err error) func cloud.google.com/go/internal/trace.StartSpan(ctx Context, name string) Context func cloud.google.com/go/internal/trace.TracePrintf(ctx Context, attrMap map[string]interface{}, format string, args ...interface{}) func cloud.google.com/go/logging.NewClient(ctx Context, parent string, opts ...option.ClientOption) (*logging.Client, error) func cloud.google.com/go/logging.(*Client).Ping(ctx Context) error func cloud.google.com/go/logging.(*Logger).LogSync(ctx Context, e logging.Entry) error func cloud.google.com/go/logging/apiv2.NewClient(ctx Context, opts ...option.ClientOption) (*logging.Client, error) func cloud.google.com/go/logging/apiv2.NewConfigClient(ctx Context, opts ...option.ClientOption) (*logging.ConfigClient, error) func cloud.google.com/go/logging/apiv2.NewMetricsClient(ctx Context, opts ...option.ClientOption) (*logging.MetricsClient, error) func cloud.google.com/go/logging/apiv2.(*Client).DeleteLog(ctx Context, req *loggingpb.DeleteLogRequest, opts ...gax.CallOption) error func cloud.google.com/go/logging/apiv2.(*Client).ListLogEntries(ctx Context, req *loggingpb.ListLogEntriesRequest, opts ...gax.CallOption) *logging.LogEntryIterator func cloud.google.com/go/logging/apiv2.(*Client).ListLogs(ctx Context, req *loggingpb.ListLogsRequest, opts ...gax.CallOption) *logging.StringIterator func cloud.google.com/go/logging/apiv2.(*Client).ListMonitoredResourceDescriptors(ctx Context, req *loggingpb.ListMonitoredResourceDescriptorsRequest, opts ...gax.CallOption) *logging.MonitoredResourceDescriptorIterator func cloud.google.com/go/logging/apiv2.(*Client).WriteLogEntries(ctx Context, req *loggingpb.WriteLogEntriesRequest, opts ...gax.CallOption) (*loggingpb.WriteLogEntriesResponse, error) func cloud.google.com/go/logging/apiv2.(*ConfigClient).CreateExclusion(ctx Context, req *loggingpb.CreateExclusionRequest, opts ...gax.CallOption) (*loggingpb.LogExclusion, error) func cloud.google.com/go/logging/apiv2.(*ConfigClient).CreateSink(ctx Context, req *loggingpb.CreateSinkRequest, opts ...gax.CallOption) (*loggingpb.LogSink, error) func cloud.google.com/go/logging/apiv2.(*ConfigClient).DeleteExclusion(ctx Context, req *loggingpb.DeleteExclusionRequest, opts ...gax.CallOption) error func cloud.google.com/go/logging/apiv2.(*ConfigClient).DeleteSink(ctx Context, req *loggingpb.DeleteSinkRequest, opts ...gax.CallOption) error func cloud.google.com/go/logging/apiv2.(*ConfigClient).GetExclusion(ctx Context, req *loggingpb.GetExclusionRequest, opts ...gax.CallOption) (*loggingpb.LogExclusion, error) func cloud.google.com/go/logging/apiv2.(*ConfigClient).GetSink(ctx Context, req *loggingpb.GetSinkRequest, opts ...gax.CallOption) (*loggingpb.LogSink, error) func cloud.google.com/go/logging/apiv2.(*ConfigClient).ListExclusions(ctx Context, req *loggingpb.ListExclusionsRequest, opts ...gax.CallOption) *logging.LogExclusionIterator func cloud.google.com/go/logging/apiv2.(*ConfigClient).ListSinks(ctx Context, req *loggingpb.ListSinksRequest, opts ...gax.CallOption) *logging.LogSinkIterator func cloud.google.com/go/logging/apiv2.(*ConfigClient).UpdateExclusion(ctx Context, req *loggingpb.UpdateExclusionRequest, opts ...gax.CallOption) (*loggingpb.LogExclusion, error) func cloud.google.com/go/logging/apiv2.(*ConfigClient).UpdateSink(ctx Context, req *loggingpb.UpdateSinkRequest, opts ...gax.CallOption) (*loggingpb.LogSink, error) func cloud.google.com/go/logging/apiv2.(*MetricsClient).CreateLogMetric(ctx Context, req *loggingpb.CreateLogMetricRequest, opts ...gax.CallOption) (*loggingpb.LogMetric, error) func cloud.google.com/go/logging/apiv2.(*MetricsClient).DeleteLogMetric(ctx Context, req *loggingpb.DeleteLogMetricRequest, opts ...gax.CallOption) error func cloud.google.com/go/logging/apiv2.(*MetricsClient).GetLogMetric(ctx Context, req *loggingpb.GetLogMetricRequest, opts ...gax.CallOption) (*loggingpb.LogMetric, error) func cloud.google.com/go/logging/apiv2.(*MetricsClient).ListLogMetrics(ctx Context, req *loggingpb.ListLogMetricsRequest, opts ...gax.CallOption) *logging.LogMetricIterator func cloud.google.com/go/logging/apiv2.(*MetricsClient).UpdateLogMetric(ctx Context, req *loggingpb.UpdateLogMetricRequest, opts ...gax.CallOption) (*loggingpb.LogMetric, error) func cloud.google.com/go/monitoring/apiv3.NewAlertPolicyClient(ctx Context, opts ...option.ClientOption) (*monitoring.AlertPolicyClient, error) func cloud.google.com/go/monitoring/apiv3.NewGroupClient(ctx Context, opts ...option.ClientOption) (*monitoring.GroupClient, error) func cloud.google.com/go/monitoring/apiv3.NewMetricClient(ctx Context, opts ...option.ClientOption) (*monitoring.MetricClient, error) func cloud.google.com/go/monitoring/apiv3.NewNotificationChannelClient(ctx Context, opts ...option.ClientOption) (*monitoring.NotificationChannelClient, error) func cloud.google.com/go/monitoring/apiv3.NewServiceMonitoringClient(ctx Context, opts ...option.ClientOption) (*monitoring.ServiceMonitoringClient, error) func cloud.google.com/go/monitoring/apiv3.NewUptimeCheckClient(ctx Context, opts ...option.ClientOption) (*monitoring.UptimeCheckClient, error) func cloud.google.com/go/monitoring/apiv3.(*AlertPolicyClient).CreateAlertPolicy(ctx Context, req *monitoringpb.CreateAlertPolicyRequest, opts ...gax.CallOption) (*monitoringpb.AlertPolicy, error) func cloud.google.com/go/monitoring/apiv3.(*AlertPolicyClient).DeleteAlertPolicy(ctx Context, req *monitoringpb.DeleteAlertPolicyRequest, opts ...gax.CallOption) error func cloud.google.com/go/monitoring/apiv3.(*AlertPolicyClient).GetAlertPolicy(ctx Context, req *monitoringpb.GetAlertPolicyRequest, opts ...gax.CallOption) (*monitoringpb.AlertPolicy, error) func cloud.google.com/go/monitoring/apiv3.(*AlertPolicyClient).ListAlertPolicies(ctx Context, req *monitoringpb.ListAlertPoliciesRequest, opts ...gax.CallOption) *monitoring.AlertPolicyIterator func cloud.google.com/go/monitoring/apiv3.(*AlertPolicyClient).UpdateAlertPolicy(ctx Context, req *monitoringpb.UpdateAlertPolicyRequest, opts ...gax.CallOption) (*monitoringpb.AlertPolicy, error) func cloud.google.com/go/monitoring/apiv3.(*GroupClient).CreateGroup(ctx Context, req *monitoringpb.CreateGroupRequest, opts ...gax.CallOption) (*monitoringpb.Group, error) func cloud.google.com/go/monitoring/apiv3.(*GroupClient).DeleteGroup(ctx Context, req *monitoringpb.DeleteGroupRequest, opts ...gax.CallOption) error func cloud.google.com/go/monitoring/apiv3.(*GroupClient).GetGroup(ctx Context, req *monitoringpb.GetGroupRequest, opts ...gax.CallOption) (*monitoringpb.Group, error) func cloud.google.com/go/monitoring/apiv3.(*GroupClient).ListGroupMembers(ctx Context, req *monitoringpb.ListGroupMembersRequest, opts ...gax.CallOption) *monitoring.MonitoredResourceIterator func cloud.google.com/go/monitoring/apiv3.(*GroupClient).ListGroups(ctx Context, req *monitoringpb.ListGroupsRequest, opts ...gax.CallOption) *monitoring.GroupIterator func cloud.google.com/go/monitoring/apiv3.(*GroupClient).UpdateGroup(ctx Context, req *monitoringpb.UpdateGroupRequest, opts ...gax.CallOption) (*monitoringpb.Group, error) func cloud.google.com/go/monitoring/apiv3.(*MetricClient).CreateMetricDescriptor(ctx Context, req *monitoringpb.CreateMetricDescriptorRequest, opts ...gax.CallOption) (*metricpb.MetricDescriptor, error) func cloud.google.com/go/monitoring/apiv3.(*MetricClient).CreateTimeSeries(ctx Context, req *monitoringpb.CreateTimeSeriesRequest, opts ...gax.CallOption) error func cloud.google.com/go/monitoring/apiv3.(*MetricClient).DeleteMetricDescriptor(ctx Context, req *monitoringpb.DeleteMetricDescriptorRequest, opts ...gax.CallOption) error func cloud.google.com/go/monitoring/apiv3.(*MetricClient).GetMetricDescriptor(ctx Context, req *monitoringpb.GetMetricDescriptorRequest, opts ...gax.CallOption) (*metricpb.MetricDescriptor, error) func cloud.google.com/go/monitoring/apiv3.(*MetricClient).GetMonitoredResourceDescriptor(ctx Context, req *monitoringpb.GetMonitoredResourceDescriptorRequest, opts ...gax.CallOption) (*monitoredrespb.MonitoredResourceDescriptor, error) func cloud.google.com/go/monitoring/apiv3.(*MetricClient).ListMetricDescriptors(ctx Context, req *monitoringpb.ListMetricDescriptorsRequest, opts ...gax.CallOption) *monitoring.MetricDescriptorIterator func cloud.google.com/go/monitoring/apiv3.(*MetricClient).ListMonitoredResourceDescriptors(ctx Context, req *monitoringpb.ListMonitoredResourceDescriptorsRequest, opts ...gax.CallOption) *monitoring.MonitoredResourceDescriptorIterator func cloud.google.com/go/monitoring/apiv3.(*MetricClient).ListTimeSeries(ctx Context, req *monitoringpb.ListTimeSeriesRequest, opts ...gax.CallOption) *monitoring.TimeSeriesIterator func cloud.google.com/go/monitoring/apiv3.(*NotificationChannelClient).CreateNotificationChannel(ctx Context, req *monitoringpb.CreateNotificationChannelRequest, opts ...gax.CallOption) (*monitoringpb.NotificationChannel, error) func cloud.google.com/go/monitoring/apiv3.(*NotificationChannelClient).DeleteNotificationChannel(ctx Context, req *monitoringpb.DeleteNotificationChannelRequest, opts ...gax.CallOption) error func cloud.google.com/go/monitoring/apiv3.(*NotificationChannelClient).GetNotificationChannel(ctx Context, req *monitoringpb.GetNotificationChannelRequest, opts ...gax.CallOption) (*monitoringpb.NotificationChannel, error) func cloud.google.com/go/monitoring/apiv3.(*NotificationChannelClient).GetNotificationChannelDescriptor(ctx Context, req *monitoringpb.GetNotificationChannelDescriptorRequest, opts ...gax.CallOption) (*monitoringpb.NotificationChannelDescriptor, error) func cloud.google.com/go/monitoring/apiv3.(*NotificationChannelClient).GetNotificationChannelVerificationCode(ctx Context, req *monitoringpb.GetNotificationChannelVerificationCodeRequest, opts ...gax.CallOption) (*monitoringpb.GetNotificationChannelVerificationCodeResponse, error) func cloud.google.com/go/monitoring/apiv3.(*NotificationChannelClient).ListNotificationChannelDescriptors(ctx Context, req *monitoringpb.ListNotificationChannelDescriptorsRequest, opts ...gax.CallOption) *monitoring.NotificationChannelDescriptorIterator func cloud.google.com/go/monitoring/apiv3.(*NotificationChannelClient).ListNotificationChannels(ctx Context, req *monitoringpb.ListNotificationChannelsRequest, opts ...gax.CallOption) *monitoring.NotificationChannelIterator func cloud.google.com/go/monitoring/apiv3.(*NotificationChannelClient).SendNotificationChannelVerificationCode(ctx Context, req *monitoringpb.SendNotificationChannelVerificationCodeRequest, opts ...gax.CallOption) error func cloud.google.com/go/monitoring/apiv3.(*NotificationChannelClient).UpdateNotificationChannel(ctx Context, req *monitoringpb.UpdateNotificationChannelRequest, opts ...gax.CallOption) (*monitoringpb.NotificationChannel, error) func cloud.google.com/go/monitoring/apiv3.(*NotificationChannelClient).VerifyNotificationChannel(ctx Context, req *monitoringpb.VerifyNotificationChannelRequest, opts ...gax.CallOption) (*monitoringpb.NotificationChannel, error) func cloud.google.com/go/monitoring/apiv3.(*ServiceMonitoringClient).CreateService(ctx Context, req *monitoringpb.CreateServiceRequest, opts ...gax.CallOption) (*monitoringpb.Service, error) func cloud.google.com/go/monitoring/apiv3.(*ServiceMonitoringClient).CreateServiceLevelObjective(ctx Context, req *monitoringpb.CreateServiceLevelObjectiveRequest, opts ...gax.CallOption) (*monitoringpb.ServiceLevelObjective, error) func cloud.google.com/go/monitoring/apiv3.(*ServiceMonitoringClient).DeleteService(ctx Context, req *monitoringpb.DeleteServiceRequest, opts ...gax.CallOption) error func cloud.google.com/go/monitoring/apiv3.(*ServiceMonitoringClient).DeleteServiceLevelObjective(ctx Context, req *monitoringpb.DeleteServiceLevelObjectiveRequest, opts ...gax.CallOption) error func cloud.google.com/go/monitoring/apiv3.(*ServiceMonitoringClient).GetService(ctx Context, req *monitoringpb.GetServiceRequest, opts ...gax.CallOption) (*monitoringpb.Service, error) func cloud.google.com/go/monitoring/apiv3.(*ServiceMonitoringClient).GetServiceLevelObjective(ctx Context, req *monitoringpb.GetServiceLevelObjectiveRequest, opts ...gax.CallOption) (*monitoringpb.ServiceLevelObjective, error) func cloud.google.com/go/monitoring/apiv3.(*ServiceMonitoringClient).ListServiceLevelObjectives(ctx Context, req *monitoringpb.ListServiceLevelObjectivesRequest, opts ...gax.CallOption) *monitoring.ServiceLevelObjectiveIterator func cloud.google.com/go/monitoring/apiv3.(*ServiceMonitoringClient).ListServices(ctx Context, req *monitoringpb.ListServicesRequest, opts ...gax.CallOption) *monitoring.ServiceIterator func cloud.google.com/go/monitoring/apiv3.(*ServiceMonitoringClient).UpdateService(ctx Context, req *monitoringpb.UpdateServiceRequest, opts ...gax.CallOption) (*monitoringpb.Service, error) func cloud.google.com/go/monitoring/apiv3.(*ServiceMonitoringClient).UpdateServiceLevelObjective(ctx Context, req *monitoringpb.UpdateServiceLevelObjectiveRequest, opts ...gax.CallOption) (*monitoringpb.ServiceLevelObjective, error) func cloud.google.com/go/monitoring/apiv3.(*UptimeCheckClient).CreateUptimeCheckConfig(ctx Context, req *monitoringpb.CreateUptimeCheckConfigRequest, opts ...gax.CallOption) (*monitoringpb.UptimeCheckConfig, error) func cloud.google.com/go/monitoring/apiv3.(*UptimeCheckClient).DeleteUptimeCheckConfig(ctx Context, req *monitoringpb.DeleteUptimeCheckConfigRequest, opts ...gax.CallOption) error func cloud.google.com/go/monitoring/apiv3.(*UptimeCheckClient).GetUptimeCheckConfig(ctx Context, req *monitoringpb.GetUptimeCheckConfigRequest, opts ...gax.CallOption) (*monitoringpb.UptimeCheckConfig, error) func cloud.google.com/go/monitoring/apiv3.(*UptimeCheckClient).ListUptimeCheckConfigs(ctx Context, req *monitoringpb.ListUptimeCheckConfigsRequest, opts ...gax.CallOption) *monitoring.UptimeCheckConfigIterator func cloud.google.com/go/monitoring/apiv3.(*UptimeCheckClient).ListUptimeCheckIps(ctx Context, req *monitoringpb.ListUptimeCheckIpsRequest, opts ...gax.CallOption) *monitoring.UptimeCheckIpIterator func cloud.google.com/go/monitoring/apiv3.(*UptimeCheckClient).UpdateUptimeCheckConfig(ctx Context, req *monitoringpb.UpdateUptimeCheckConfigRequest, opts ...gax.CallOption) (*monitoringpb.UptimeCheckConfig, error) func cloud.google.com/go/secretmanager/apiv1.NewClient(ctx Context, opts ...option.ClientOption) (*secretmanager.Client, error) func cloud.google.com/go/secretmanager/apiv1.(*Client).AccessSecretVersion(ctx Context, req *secretmanagerpb.AccessSecretVersionRequest, opts ...gax.CallOption) (*secretmanagerpb.AccessSecretVersionResponse, error) func cloud.google.com/go/secretmanager/apiv1.(*Client).AddSecretVersion(ctx Context, req *secretmanagerpb.AddSecretVersionRequest, opts ...gax.CallOption) (*secretmanagerpb.SecretVersion, error) func cloud.google.com/go/secretmanager/apiv1.(*Client).CreateSecret(ctx Context, req *secretmanagerpb.CreateSecretRequest, opts ...gax.CallOption) (*secretmanagerpb.Secret, error) func cloud.google.com/go/secretmanager/apiv1.(*Client).DeleteSecret(ctx Context, req *secretmanagerpb.DeleteSecretRequest, opts ...gax.CallOption) error func cloud.google.com/go/secretmanager/apiv1.(*Client).DestroySecretVersion(ctx Context, req *secretmanagerpb.DestroySecretVersionRequest, opts ...gax.CallOption) (*secretmanagerpb.SecretVersion, error) func cloud.google.com/go/secretmanager/apiv1.(*Client).DisableSecretVersion(ctx Context, req *secretmanagerpb.DisableSecretVersionRequest, opts ...gax.CallOption) (*secretmanagerpb.SecretVersion, error) func cloud.google.com/go/secretmanager/apiv1.(*Client).EnableSecretVersion(ctx Context, req *secretmanagerpb.EnableSecretVersionRequest, opts ...gax.CallOption) (*secretmanagerpb.SecretVersion, error) func cloud.google.com/go/secretmanager/apiv1.(*Client).GetIamPolicy(ctx Context, req *iampb.GetIamPolicyRequest, opts ...gax.CallOption) (*iampb.Policy, error) func cloud.google.com/go/secretmanager/apiv1.(*Client).GetSecret(ctx Context, req *secretmanagerpb.GetSecretRequest, opts ...gax.CallOption) (*secretmanagerpb.Secret, error) func cloud.google.com/go/secretmanager/apiv1.(*Client).GetSecretVersion(ctx Context, req *secretmanagerpb.GetSecretVersionRequest, opts ...gax.CallOption) (*secretmanagerpb.SecretVersion, error) func cloud.google.com/go/secretmanager/apiv1.(*Client).ListSecrets(ctx Context, req *secretmanagerpb.ListSecretsRequest, opts ...gax.CallOption) *secretmanager.SecretIterator func cloud.google.com/go/secretmanager/apiv1.(*Client).ListSecretVersions(ctx Context, req *secretmanagerpb.ListSecretVersionsRequest, opts ...gax.CallOption) *secretmanager.SecretVersionIterator func cloud.google.com/go/secretmanager/apiv1.(*Client).SetIamPolicy(ctx Context, req *iampb.SetIamPolicyRequest, opts ...gax.CallOption) (*iampb.Policy, error) func cloud.google.com/go/secretmanager/apiv1.(*Client).TestIamPermissions(ctx Context, req *iampb.TestIamPermissionsRequest, opts ...gax.CallOption) (*iampb.TestIamPermissionsResponse, error) func cloud.google.com/go/secretmanager/apiv1.(*Client).UpdateSecret(ctx Context, req *secretmanagerpb.UpdateSecretRequest, opts ...gax.CallOption) (*secretmanagerpb.Secret, error) func cloud.google.com/go/storage.NewClient(ctx Context, opts ...option.ClientOption) (*storage.Client, error) func cloud.google.com/go/storage.(*ACLHandle).Delete(ctx Context, entity storage.ACLEntity) (err error) func cloud.google.com/go/storage.(*ACLHandle).List(ctx Context) (rules []storage.ACLRule, err error) func cloud.google.com/go/storage.(*ACLHandle).Set(ctx Context, entity storage.ACLEntity, role storage.ACLRole) (err error) func cloud.google.com/go/storage.(*BucketHandle).AddNotification(ctx Context, n *storage.Notification) (ret *storage.Notification, err error) func cloud.google.com/go/storage.(*BucketHandle).Attrs(ctx Context) (attrs *storage.BucketAttrs, err error) func cloud.google.com/go/storage.(*BucketHandle).Create(ctx Context, projectID string, attrs *storage.BucketAttrs) (err error) func cloud.google.com/go/storage.(*BucketHandle).Delete(ctx Context) (err error) func cloud.google.com/go/storage.(*BucketHandle).DeleteNotification(ctx Context, id string) (err error) func cloud.google.com/go/storage.(*BucketHandle).LockRetentionPolicy(ctx Context) error func cloud.google.com/go/storage.(*BucketHandle).Notifications(ctx Context) (n map[string]*storage.Notification, err error) func cloud.google.com/go/storage.(*BucketHandle).Objects(ctx Context, q *storage.Query) *storage.ObjectIterator func cloud.google.com/go/storage.(*BucketHandle).Update(ctx Context, uattrs storage.BucketAttrsToUpdate) (attrs *storage.BucketAttrs, err error) func cloud.google.com/go/storage.(*Client).Buckets(ctx Context, projectID string) *storage.BucketIterator func cloud.google.com/go/storage.(*Client).CreateHMACKey(ctx Context, projectID, serviceAccountEmail string, opts ...storage.HMACKeyOption) (*storage.HMACKey, error) func cloud.google.com/go/storage.(*Client).ListHMACKeys(ctx Context, projectID string, opts ...storage.HMACKeyOption) *storage.HMACKeysIterator func cloud.google.com/go/storage.(*Client).ServiceAccount(ctx Context, projectID string) (string, error) func cloud.google.com/go/storage.(*Composer).Run(ctx Context) (attrs *storage.ObjectAttrs, err error) func cloud.google.com/go/storage.(*Copier).Run(ctx Context) (attrs *storage.ObjectAttrs, err error) func cloud.google.com/go/storage.(*HMACKeyHandle).Delete(ctx Context, opts ...storage.HMACKeyOption) error func cloud.google.com/go/storage.(*HMACKeyHandle).Get(ctx Context, opts ...storage.HMACKeyOption) (*storage.HMACKey, error) func cloud.google.com/go/storage.(*HMACKeyHandle).Update(ctx Context, au storage.HMACKeyAttrsToUpdate, opts ...storage.HMACKeyOption) (*storage.HMACKey, error) func cloud.google.com/go/storage.(*ObjectHandle).Attrs(ctx Context) (attrs *storage.ObjectAttrs, err error) func cloud.google.com/go/storage.(*ObjectHandle).Delete(ctx Context) error func cloud.google.com/go/storage.(*ObjectHandle).NewRangeReader(ctx Context, offset, length int64) (r *storage.Reader, err error) func cloud.google.com/go/storage.(*ObjectHandle).NewReader(ctx Context) (*storage.Reader, error) func cloud.google.com/go/storage.(*ObjectHandle).NewWriter(ctx Context) *storage.Writer func cloud.google.com/go/storage.(*ObjectHandle).Update(ctx Context, uattrs storage.ObjectAttrsToUpdate) (oa *storage.ObjectAttrs, err error) func cloud.google.com/go/trace/apiv2.NewClient(ctx Context, opts ...option.ClientOption) (*trace.Client, error) func cloud.google.com/go/trace/apiv2.(*Client).BatchWriteSpans(ctx Context, req *cloudtracepb.BatchWriteSpansRequest, opts ...gax.CallOption) error func cloud.google.com/go/trace/apiv2.(*Client).CreateSpan(ctx Context, req *cloudtracepb.Span, opts ...gax.CallOption) (*cloudtracepb.Span, error) func contrib.go.opencensus.io/exporter/stackdriver.(*Exporter).ExportMetrics(ctx Context, metrics []*metricdata.Metric) error func contrib.go.opencensus.io/exporter/stackdriver.(*Exporter).ExportMetricsProto(ctx Context, node *commonpb.Node, rsc *resourcepb.Resource, metrics []*metricspb.Metric) error func contrib.go.opencensus.io/exporter/stackdriver.(*Exporter).PushMetricsProto(ctx Context, node *commonpb.Node, rsc *resourcepb.Resource, metrics []*metricspb.Metric) (int, error) func contrib.go.opencensus.io/exporter/stackdriver.(*Exporter).PushTraceSpans(ctx Context, node *commonpb.Node, rsc *resourcepb.Resource, spans []*trace.SpanData) (int, error) func crypto/tls.(*Dialer).DialContext(ctx Context, network, addr string) (net.Conn, error) func database/sql.(*Conn).BeginTx(ctx Context, opts *sql.TxOptions) (*sql.Tx, error) func database/sql.(*Conn).ExecContext(ctx Context, query string, args ...interface{}) (sql.Result, error) func database/sql.(*Conn).PingContext(ctx Context) error func database/sql.(*Conn).PrepareContext(ctx Context, query string) (*sql.Stmt, error) func database/sql.(*Conn).QueryContext(ctx Context, query string, args ...interface{}) (*sql.Rows, error) func database/sql.(*Conn).QueryRowContext(ctx Context, query string, args ...interface{}) *sql.Row func database/sql.(*DB).BeginTx(ctx Context, opts *sql.TxOptions) (*sql.Tx, error) func database/sql.(*DB).Conn(ctx Context) (*sql.Conn, error) func database/sql.(*DB).ExecContext(ctx Context, query string, args ...interface{}) (sql.Result, error) func database/sql.(*DB).PingContext(ctx Context) error func database/sql.(*DB).PrepareContext(ctx Context, query string) (*sql.Stmt, error) func database/sql.(*DB).QueryContext(ctx Context, query string, args ...interface{}) (*sql.Rows, error) func database/sql.(*DB).QueryRowContext(ctx Context, query string, args ...interface{}) *sql.Row func database/sql.(*Stmt).ExecContext(ctx Context, args ...interface{}) (sql.Result, error) func database/sql.(*Stmt).QueryContext(ctx Context, args ...interface{}) (*sql.Rows, error) func database/sql.(*Stmt).QueryRowContext(ctx Context, args ...interface{}) *sql.Row func database/sql.(*Tx).ExecContext(ctx Context, query string, args ...interface{}) (sql.Result, error) func database/sql.(*Tx).PrepareContext(ctx Context, query string) (*sql.Stmt, error) func database/sql.(*Tx).QueryContext(ctx Context, query string, args ...interface{}) (*sql.Rows, error) func database/sql.(*Tx).QueryRowContext(ctx Context, query string, args ...interface{}) *sql.Row func database/sql.(*Tx).StmtContext(ctx Context, stmt *sql.Stmt) *sql.Stmt func database/sql/driver.ConnBeginTx.BeginTx(ctx Context, opts driver.TxOptions) (driver.Tx, error) func database/sql/driver.Connector.Connect(Context) (driver.Conn, error) func database/sql/driver.ConnPrepareContext.PrepareContext(ctx Context, query string) (driver.Stmt, error) func database/sql/driver.ExecerContext.ExecContext(ctx Context, query string, args []driver.NamedValue) (driver.Result, error) func database/sql/driver.Pinger.Ping(ctx Context) error func database/sql/driver.QueryerContext.QueryContext(ctx Context, query string, args []driver.NamedValue) (driver.Rows, error) func database/sql/driver.SessionResetter.ResetSession(ctx Context) error func database/sql/driver.StmtExecContext.ExecContext(ctx Context, args []driver.NamedValue) (driver.Result, error) func database/sql/driver.StmtQueryContext.QueryContext(ctx Context, args []driver.NamedValue) (driver.Rows, error) func github.com/aws/aws-sdk-go/aws.SleepWithContext(ctx aws.Context, dur time.Duration) error func github.com/aws/aws-sdk-go/aws/credentials.(*Credentials).GetWithContext(ctx credentials.Context) (credentials.Value, error) func github.com/aws/aws-sdk-go/aws/credentials.ProviderWithContext.RetrieveWithContext(credentials.Context) (credentials.Value, error) func github.com/aws/aws-sdk-go/aws/credentials/ec2rolecreds.(*EC2RoleProvider).RetrieveWithContext(ctx credentials.Context) (credentials.Value, error) func github.com/aws/aws-sdk-go/aws/credentials/endpointcreds.(*Provider).RetrieveWithContext(ctx credentials.Context) (credentials.Value, error) func github.com/aws/aws-sdk-go/aws/credentials/stscreds.(*AssumeRoleProvider).RetrieveWithContext(ctx credentials.Context) (credentials.Value, error) func github.com/aws/aws-sdk-go/aws/credentials/stscreds.FetchTokenPath.FetchToken(ctx credentials.Context) ([]byte, error) func github.com/aws/aws-sdk-go/aws/credentials/stscreds.TokenFetcher.FetchToken(credentials.Context) ([]byte, error) func github.com/aws/aws-sdk-go/aws/credentials/stscreds.(*WebIdentityRoleProvider).RetrieveWithContext(ctx credentials.Context) (credentials.Value, error) func github.com/aws/aws-sdk-go/aws/ec2metadata.(*EC2Metadata).AvailableWithContext(ctx aws.Context) bool func github.com/aws/aws-sdk-go/aws/ec2metadata.(*EC2Metadata).GetDynamicDataWithContext(ctx aws.Context, p string) (string, error) func github.com/aws/aws-sdk-go/aws/ec2metadata.(*EC2Metadata).GetInstanceIdentityDocumentWithContext(ctx aws.Context) (ec2metadata.EC2InstanceIdentityDocument, error) func github.com/aws/aws-sdk-go/aws/ec2metadata.(*EC2Metadata).GetMetadataWithContext(ctx aws.Context, p string) (string, error) func github.com/aws/aws-sdk-go/aws/ec2metadata.(*EC2Metadata).GetUserDataWithContext(ctx aws.Context) (string, error) func github.com/aws/aws-sdk-go/aws/ec2metadata.(*EC2Metadata).IAMInfoWithContext(ctx aws.Context) (ec2metadata.EC2IAMInfo, error) func github.com/aws/aws-sdk-go/aws/ec2metadata.(*EC2Metadata).RegionWithContext(ctx aws.Context) (string, error) func github.com/aws/aws-sdk-go/aws/request.(*Request).SetContext(ctx aws.Context) func github.com/aws/aws-sdk-go/aws/request.Waiter.WaitWithContext(ctx aws.Context) error func github.com/aws/aws-sdk-go/service/sts.(*STS).AssumeRoleWithContext(ctx aws.Context, input *sts.AssumeRoleInput, opts ...request.Option) (*sts.AssumeRoleOutput, error) func github.com/aws/aws-sdk-go/service/sts.(*STS).AssumeRoleWithSAMLWithContext(ctx aws.Context, input *sts.AssumeRoleWithSAMLInput, opts ...request.Option) (*sts.AssumeRoleWithSAMLOutput, error) func github.com/aws/aws-sdk-go/service/sts.(*STS).AssumeRoleWithWebIdentityWithContext(ctx aws.Context, input *sts.AssumeRoleWithWebIdentityInput, opts ...request.Option) (*sts.AssumeRoleWithWebIdentityOutput, error) func github.com/aws/aws-sdk-go/service/sts.(*STS).DecodeAuthorizationMessageWithContext(ctx aws.Context, input *sts.DecodeAuthorizationMessageInput, opts ...request.Option) (*sts.DecodeAuthorizationMessageOutput, error) func github.com/aws/aws-sdk-go/service/sts.(*STS).GetAccessKeyInfoWithContext(ctx aws.Context, input *sts.GetAccessKeyInfoInput, opts ...request.Option) (*sts.GetAccessKeyInfoOutput, error) func github.com/aws/aws-sdk-go/service/sts.(*STS).GetCallerIdentityWithContext(ctx aws.Context, input *sts.GetCallerIdentityInput, opts ...request.Option) (*sts.GetCallerIdentityOutput, error) func github.com/aws/aws-sdk-go/service/sts.(*STS).GetFederationTokenWithContext(ctx aws.Context, input *sts.GetFederationTokenInput, opts ...request.Option) (*sts.GetFederationTokenOutput, error) func github.com/aws/aws-sdk-go/service/sts.(*STS).GetSessionTokenWithContext(ctx aws.Context, input *sts.GetSessionTokenInput, opts ...request.Option) (*sts.GetSessionTokenOutput, error) func github.com/aws/aws-sdk-go/service/sts/stsiface.STSAPI.AssumeRoleWithContext(aws.Context, *sts.AssumeRoleInput, ...request.Option) (*sts.AssumeRoleOutput, error) func github.com/aws/aws-sdk-go/service/sts/stsiface.STSAPI.AssumeRoleWithSAMLWithContext(aws.Context, *sts.AssumeRoleWithSAMLInput, ...request.Option) (*sts.AssumeRoleWithSAMLOutput, error) func github.com/aws/aws-sdk-go/service/sts/stsiface.STSAPI.AssumeRoleWithWebIdentityWithContext(aws.Context, *sts.AssumeRoleWithWebIdentityInput, ...request.Option) (*sts.AssumeRoleWithWebIdentityOutput, error) func github.com/aws/aws-sdk-go/service/sts/stsiface.STSAPI.DecodeAuthorizationMessageWithContext(aws.Context, *sts.DecodeAuthorizationMessageInput, ...request.Option) (*sts.DecodeAuthorizationMessageOutput, error) func github.com/aws/aws-sdk-go/service/sts/stsiface.STSAPI.GetAccessKeyInfoWithContext(aws.Context, *sts.GetAccessKeyInfoInput, ...request.Option) (*sts.GetAccessKeyInfoOutput, error) func github.com/aws/aws-sdk-go/service/sts/stsiface.STSAPI.GetCallerIdentityWithContext(aws.Context, *sts.GetCallerIdentityInput, ...request.Option) (*sts.GetCallerIdentityOutput, error) func github.com/aws/aws-sdk-go/service/sts/stsiface.STSAPI.GetFederationTokenWithContext(aws.Context, *sts.GetFederationTokenInput, ...request.Option) (*sts.GetFederationTokenOutput, error) func github.com/aws/aws-sdk-go/service/sts/stsiface.STSAPI.GetSessionTokenWithContext(aws.Context, *sts.GetSessionTokenInput, ...request.Option) (*sts.GetSessionTokenOutput, error) func github.com/go-git/go-git/v5.CloneContext(ctx Context, s storage.Storer, worktree billy.Filesystem, o *git.CloneOptions) (*git.Repository, error) func github.com/go-git/go-git/v5.PlainCloneContext(ctx Context, path string, isBare bool, o *git.CloneOptions) (*git.Repository, error) func github.com/go-git/go-git/v5.(*Remote).FetchContext(ctx Context, o *git.FetchOptions) error func github.com/go-git/go-git/v5.(*Remote).PushContext(ctx Context, o *git.PushOptions) (err error) func github.com/go-git/go-git/v5.(*Repository).FetchContext(ctx Context, o *git.FetchOptions) error func github.com/go-git/go-git/v5.(*Repository).PushContext(ctx Context, o *git.PushOptions) error func github.com/go-git/go-git/v5.(*Submodule).UpdateContext(ctx Context, o *git.SubmoduleUpdateOptions) error func github.com/go-git/go-git/v5.Submodules.UpdateContext(ctx Context, o *git.SubmoduleUpdateOptions) error func github.com/go-git/go-git/v5.(*Worktree).PullContext(ctx Context, o *git.PullOptions) error func github.com/go-git/go-git/v5/plumbing/object.DiffTreeContext(ctx Context, a, b *object.Tree) (object.Changes, error) func github.com/go-git/go-git/v5/plumbing/object.DiffTreeWithOptions(ctx Context, a, b *object.Tree, opts *object.DiffTreeOptions) (object.Changes, error) func github.com/go-git/go-git/v5/plumbing/object.(*Change).PatchContext(ctx Context) (*object.Patch, error) func github.com/go-git/go-git/v5/plumbing/object.Changes.PatchContext(ctx Context) (*object.Patch, error) func github.com/go-git/go-git/v5/plumbing/object.(*Commit).PatchContext(ctx Context, to *object.Commit) (*object.Patch, error) func github.com/go-git/go-git/v5/plumbing/object.(*Commit).StatsContext(ctx Context) (object.FileStats, error) func github.com/go-git/go-git/v5/plumbing/object.(*Tree).DiffContext(ctx Context, to *object.Tree) (object.Changes, error) func github.com/go-git/go-git/v5/plumbing/object.(*Tree).PatchContext(ctx Context, to *object.Tree) (*object.Patch, error) func github.com/go-git/go-git/v5/plumbing/transport.ReceivePackSession.ReceivePack(Context, *packp.ReferenceUpdateRequest) (*packp.ReportStatus, error) func github.com/go-git/go-git/v5/plumbing/transport.UploadPackSession.UploadPack(Context, *packp.UploadPackRequest) (*packp.UploadPackResponse, error) func github.com/go-git/go-git/v5/utils/ioutil.NewContextReadCloser(ctx Context, r io.ReadCloser) io.ReadCloser func github.com/go-git/go-git/v5/utils/ioutil.NewContextReader(ctx Context, r io.Reader) io.Reader func github.com/go-git/go-git/v5/utils/ioutil.NewContextWriteCloser(ctx Context, w io.WriteCloser) io.WriteCloser func github.com/go-git/go-git/v5/utils/ioutil.NewContextWriter(ctx Context, w io.Writer) io.Writer func github.com/go-git/go-git/v5/utils/merkletrie.DiffTreeContext(ctx Context, fromTree, toTree noder.Noder, hashEqual noder.Equal) (merkletrie.Changes, error) func github.com/go-redis/redis/v8.NewBoolCmd(ctx Context, args ...interface{}) *redis.BoolCmd func github.com/go-redis/redis/v8.NewBoolSliceCmd(ctx Context, args ...interface{}) *redis.BoolSliceCmd func github.com/go-redis/redis/v8.NewClusterSlotsCmd(ctx Context, args ...interface{}) *redis.ClusterSlotsCmd func github.com/go-redis/redis/v8.NewCmd(ctx Context, args ...interface{}) *redis.Cmd func github.com/go-redis/redis/v8.NewCommandsInfoCmd(ctx Context, args ...interface{}) *redis.CommandsInfoCmd func github.com/go-redis/redis/v8.NewDurationCmd(ctx Context, precision time.Duration, args ...interface{}) *redis.DurationCmd func github.com/go-redis/redis/v8.NewFloatCmd(ctx Context, args ...interface{}) *redis.FloatCmd func github.com/go-redis/redis/v8.NewGeoLocationCmd(ctx Context, q *redis.GeoRadiusQuery, args ...interface{}) *redis.GeoLocationCmd func github.com/go-redis/redis/v8.NewGeoPosCmd(ctx Context, args ...interface{}) *redis.GeoPosCmd func github.com/go-redis/redis/v8.NewIntCmd(ctx Context, args ...interface{}) *redis.IntCmd func github.com/go-redis/redis/v8.NewIntSliceCmd(ctx Context, args ...interface{}) *redis.IntSliceCmd func github.com/go-redis/redis/v8.NewScanCmd(ctx Context, process redis.cmdable, args ...interface{}) *redis.ScanCmd func github.com/go-redis/redis/v8.NewSliceCmd(ctx Context, args ...interface{}) *redis.SliceCmd func github.com/go-redis/redis/v8.NewSlowLogCmd(ctx Context, args ...interface{}) *redis.SlowLogCmd func github.com/go-redis/redis/v8.NewStatusCmd(ctx Context, args ...interface{}) *redis.StatusCmd func github.com/go-redis/redis/v8.NewStringCmd(ctx Context, args ...interface{}) *redis.StringCmd func github.com/go-redis/redis/v8.NewStringIntMapCmd(ctx Context, args ...interface{}) *redis.StringIntMapCmd func github.com/go-redis/redis/v8.NewStringSliceCmd(ctx Context, args ...interface{}) *redis.StringSliceCmd func github.com/go-redis/redis/v8.NewStringStringMapCmd(ctx Context, args ...interface{}) *redis.StringStringMapCmd func github.com/go-redis/redis/v8.NewStringStructMapCmd(ctx Context, args ...interface{}) *redis.StringStructMapCmd func github.com/go-redis/redis/v8.NewTimeCmd(ctx Context, args ...interface{}) *redis.TimeCmd func github.com/go-redis/redis/v8.NewXInfoGroupsCmd(ctx Context, stream string) *redis.XInfoGroupsCmd func github.com/go-redis/redis/v8.NewXMessageSliceCmd(ctx Context, args ...interface{}) *redis.XMessageSliceCmd func github.com/go-redis/redis/v8.NewXPendingCmd(ctx Context, args ...interface{}) *redis.XPendingCmd func github.com/go-redis/redis/v8.NewXPendingExtCmd(ctx Context, args ...interface{}) *redis.XPendingExtCmd func github.com/go-redis/redis/v8.NewXStreamSliceCmd(ctx Context, args ...interface{}) *redis.XStreamSliceCmd func github.com/go-redis/redis/v8.NewZSliceCmd(ctx Context, args ...interface{}) *redis.ZSliceCmd func github.com/go-redis/redis/v8.NewZWithKeyCmd(ctx Context, args ...interface{}) *redis.ZWithKeyCmd func github.com/go-redis/redis/v8.(*Client).Conn(ctx Context) *redis.Conn func github.com/go-redis/redis/v8.(*Client).Do(ctx Context, args ...interface{}) *redis.Cmd func github.com/go-redis/redis/v8.(*Client).Pipelined(ctx Context, fn func(redis.Pipeliner) error) ([]redis.Cmder, error) func github.com/go-redis/redis/v8.(*Client).Process(ctx Context, cmd redis.Cmder) error func github.com/go-redis/redis/v8.(*Client).PSubscribe(ctx Context, channels ...string) *redis.PubSub func github.com/go-redis/redis/v8.(*Client).Subscribe(ctx Context, channels ...string) *redis.PubSub func github.com/go-redis/redis/v8.(*Client).TxPipelined(ctx Context, fn func(redis.Pipeliner) error) ([]redis.Cmder, error) func github.com/go-redis/redis/v8.(*Client).Watch(ctx Context, fn func(*redis.Tx) error, keys ...string) error func github.com/go-redis/redis/v8.(*Client).WithContext(ctx Context) *redis.Client func github.com/go-redis/redis/v8.(*ClusterClient).DBSize(ctx Context) *redis.IntCmd func github.com/go-redis/redis/v8.(*ClusterClient).Do(ctx Context, args ...interface{}) *redis.Cmd func github.com/go-redis/redis/v8.(*ClusterClient).ForEachMaster(ctx Context, fn func(ctx Context, client *redis.Client) error) error func github.com/go-redis/redis/v8.(*ClusterClient).ForEachShard(ctx Context, fn func(ctx Context, client *redis.Client) error) error func github.com/go-redis/redis/v8.(*ClusterClient).ForEachSlave(ctx Context, fn func(ctx Context, client *redis.Client) error) error func github.com/go-redis/redis/v8.(*ClusterClient).Pipelined(ctx Context, fn func(redis.Pipeliner) error) ([]redis.Cmder, error) func github.com/go-redis/redis/v8.(*ClusterClient).Process(ctx Context, cmd redis.Cmder) error func github.com/go-redis/redis/v8.(*ClusterClient).PSubscribe(ctx Context, channels ...string) *redis.PubSub func github.com/go-redis/redis/v8.(*ClusterClient).ReloadState(ctx Context) func github.com/go-redis/redis/v8.(*ClusterClient).Subscribe(ctx Context, channels ...string) *redis.PubSub func github.com/go-redis/redis/v8.(*ClusterClient).TxPipelined(ctx Context, fn func(redis.Pipeliner) error) ([]redis.Cmder, error) func github.com/go-redis/redis/v8.(*ClusterClient).Watch(ctx Context, fn func(*redis.Tx) error, keys ...string) error func github.com/go-redis/redis/v8.(*ClusterClient).WithContext(ctx Context) *redis.ClusterClient func github.com/go-redis/redis/v8.Cmdable.Append(ctx Context, key, value string) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.BgRewriteAOF(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.Cmdable.BgSave(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.Cmdable.BitCount(ctx Context, key string, bitCount *redis.BitCount) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.BitField(ctx Context, key string, args ...interface{}) *redis.IntSliceCmd func github.com/go-redis/redis/v8.Cmdable.BitOpAnd(ctx Context, destKey string, keys ...string) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.BitOpNot(ctx Context, destKey string, key string) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.BitOpOr(ctx Context, destKey string, keys ...string) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.BitOpXor(ctx Context, destKey string, keys ...string) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.BitPos(ctx Context, key string, bit int64, pos ...int64) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.BLPop(ctx Context, timeout time.Duration, keys ...string) *redis.StringSliceCmd func github.com/go-redis/redis/v8.Cmdable.BRPop(ctx Context, timeout time.Duration, keys ...string) *redis.StringSliceCmd func github.com/go-redis/redis/v8.Cmdable.BRPopLPush(ctx Context, source, destination string, timeout time.Duration) *redis.StringCmd func github.com/go-redis/redis/v8.Cmdable.BZPopMax(ctx Context, timeout time.Duration, keys ...string) *redis.ZWithKeyCmd func github.com/go-redis/redis/v8.Cmdable.BZPopMin(ctx Context, timeout time.Duration, keys ...string) *redis.ZWithKeyCmd func github.com/go-redis/redis/v8.Cmdable.ClientGetName(ctx Context) *redis.StringCmd func github.com/go-redis/redis/v8.Cmdable.ClientID(ctx Context) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.ClientKill(ctx Context, ipPort string) *redis.StatusCmd func github.com/go-redis/redis/v8.Cmdable.ClientKillByFilter(ctx Context, keys ...string) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.ClientList(ctx Context) *redis.StringCmd func github.com/go-redis/redis/v8.Cmdable.ClientPause(ctx Context, dur time.Duration) *redis.BoolCmd func github.com/go-redis/redis/v8.Cmdable.ClusterAddSlots(ctx Context, slots ...int) *redis.StatusCmd func github.com/go-redis/redis/v8.Cmdable.ClusterAddSlotsRange(ctx Context, min, max int) *redis.StatusCmd func github.com/go-redis/redis/v8.Cmdable.ClusterCountFailureReports(ctx Context, nodeID string) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.ClusterCountKeysInSlot(ctx Context, slot int) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.ClusterDelSlots(ctx Context, slots ...int) *redis.StatusCmd func github.com/go-redis/redis/v8.Cmdable.ClusterDelSlotsRange(ctx Context, min, max int) *redis.StatusCmd func github.com/go-redis/redis/v8.Cmdable.ClusterFailover(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.Cmdable.ClusterForget(ctx Context, nodeID string) *redis.StatusCmd func github.com/go-redis/redis/v8.Cmdable.ClusterGetKeysInSlot(ctx Context, slot int, count int) *redis.StringSliceCmd func github.com/go-redis/redis/v8.Cmdable.ClusterInfo(ctx Context) *redis.StringCmd func github.com/go-redis/redis/v8.Cmdable.ClusterKeySlot(ctx Context, key string) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.ClusterMeet(ctx Context, host, port string) *redis.StatusCmd func github.com/go-redis/redis/v8.Cmdable.ClusterNodes(ctx Context) *redis.StringCmd func github.com/go-redis/redis/v8.Cmdable.ClusterReplicate(ctx Context, nodeID string) *redis.StatusCmd func github.com/go-redis/redis/v8.Cmdable.ClusterResetHard(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.Cmdable.ClusterResetSoft(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.Cmdable.ClusterSaveConfig(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.Cmdable.ClusterSlaves(ctx Context, nodeID string) *redis.StringSliceCmd func github.com/go-redis/redis/v8.Cmdable.ClusterSlots(ctx Context) *redis.ClusterSlotsCmd func github.com/go-redis/redis/v8.Cmdable.Command(ctx Context) *redis.CommandsInfoCmd func github.com/go-redis/redis/v8.Cmdable.ConfigGet(ctx Context, parameter string) *redis.SliceCmd func github.com/go-redis/redis/v8.Cmdable.ConfigResetStat(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.Cmdable.ConfigRewrite(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.Cmdable.ConfigSet(ctx Context, parameter, value string) *redis.StatusCmd func github.com/go-redis/redis/v8.Cmdable.DBSize(ctx Context) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.DebugObject(ctx Context, key string) *redis.StringCmd func github.com/go-redis/redis/v8.Cmdable.Decr(ctx Context, key string) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.DecrBy(ctx Context, key string, decrement int64) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.Del(ctx Context, keys ...string) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.Dump(ctx Context, key string) *redis.StringCmd func github.com/go-redis/redis/v8.Cmdable.Echo(ctx Context, message interface{}) *redis.StringCmd func github.com/go-redis/redis/v8.Cmdable.Eval(ctx Context, script string, keys []string, args ...interface{}) *redis.Cmd func github.com/go-redis/redis/v8.Cmdable.EvalSha(ctx Context, sha1 string, keys []string, args ...interface{}) *redis.Cmd func github.com/go-redis/redis/v8.Cmdable.Exists(ctx Context, keys ...string) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.Expire(ctx Context, key string, expiration time.Duration) *redis.BoolCmd func github.com/go-redis/redis/v8.Cmdable.ExpireAt(ctx Context, key string, tm time.Time) *redis.BoolCmd func github.com/go-redis/redis/v8.Cmdable.FlushAll(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.Cmdable.FlushAllAsync(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.Cmdable.FlushDB(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.Cmdable.FlushDBAsync(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.Cmdable.GeoAdd(ctx Context, key string, geoLocation ...*redis.GeoLocation) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.GeoDist(ctx Context, key string, member1, member2, unit string) *redis.FloatCmd func github.com/go-redis/redis/v8.Cmdable.GeoHash(ctx Context, key string, members ...string) *redis.StringSliceCmd func github.com/go-redis/redis/v8.Cmdable.GeoPos(ctx Context, key string, members ...string) *redis.GeoPosCmd func github.com/go-redis/redis/v8.Cmdable.GeoRadius(ctx Context, key string, longitude, latitude float64, query *redis.GeoRadiusQuery) *redis.GeoLocationCmd func github.com/go-redis/redis/v8.Cmdable.GeoRadiusByMember(ctx Context, key, member string, query *redis.GeoRadiusQuery) *redis.GeoLocationCmd func github.com/go-redis/redis/v8.Cmdable.GeoRadiusByMemberStore(ctx Context, key, member string, query *redis.GeoRadiusQuery) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.GeoRadiusStore(ctx Context, key string, longitude, latitude float64, query *redis.GeoRadiusQuery) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.Get(ctx Context, key string) *redis.StringCmd func github.com/go-redis/redis/v8.Cmdable.GetBit(ctx Context, key string, offset int64) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.GetRange(ctx Context, key string, start, end int64) *redis.StringCmd func github.com/go-redis/redis/v8.Cmdable.GetSet(ctx Context, key string, value interface{}) *redis.StringCmd func github.com/go-redis/redis/v8.Cmdable.HDel(ctx Context, key string, fields ...string) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.HExists(ctx Context, key, field string) *redis.BoolCmd func github.com/go-redis/redis/v8.Cmdable.HGet(ctx Context, key, field string) *redis.StringCmd func github.com/go-redis/redis/v8.Cmdable.HGetAll(ctx Context, key string) *redis.StringStringMapCmd func github.com/go-redis/redis/v8.Cmdable.HIncrBy(ctx Context, key, field string, incr int64) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.HIncrByFloat(ctx Context, key, field string, incr float64) *redis.FloatCmd func github.com/go-redis/redis/v8.Cmdable.HKeys(ctx Context, key string) *redis.StringSliceCmd func github.com/go-redis/redis/v8.Cmdable.HLen(ctx Context, key string) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.HMGet(ctx Context, key string, fields ...string) *redis.SliceCmd func github.com/go-redis/redis/v8.Cmdable.HMSet(ctx Context, key string, values ...interface{}) *redis.BoolCmd func github.com/go-redis/redis/v8.Cmdable.HScan(ctx Context, key string, cursor uint64, match string, count int64) *redis.ScanCmd func github.com/go-redis/redis/v8.Cmdable.HSet(ctx Context, key string, values ...interface{}) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.HSetNX(ctx Context, key, field string, value interface{}) *redis.BoolCmd func github.com/go-redis/redis/v8.Cmdable.HVals(ctx Context, key string) *redis.StringSliceCmd func github.com/go-redis/redis/v8.Cmdable.Incr(ctx Context, key string) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.IncrBy(ctx Context, key string, value int64) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.IncrByFloat(ctx Context, key string, value float64) *redis.FloatCmd func github.com/go-redis/redis/v8.Cmdable.Info(ctx Context, section ...string) *redis.StringCmd func github.com/go-redis/redis/v8.Cmdable.Keys(ctx Context, pattern string) *redis.StringSliceCmd func github.com/go-redis/redis/v8.Cmdable.LastSave(ctx Context) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.LIndex(ctx Context, key string, index int64) *redis.StringCmd func github.com/go-redis/redis/v8.Cmdable.LInsert(ctx Context, key, op string, pivot, value interface{}) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.LInsertAfter(ctx Context, key string, pivot, value interface{}) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.LInsertBefore(ctx Context, key string, pivot, value interface{}) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.LLen(ctx Context, key string) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.LPop(ctx Context, key string) *redis.StringCmd func github.com/go-redis/redis/v8.Cmdable.LPush(ctx Context, key string, values ...interface{}) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.LPushX(ctx Context, key string, values ...interface{}) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.LRange(ctx Context, key string, start, stop int64) *redis.StringSliceCmd func github.com/go-redis/redis/v8.Cmdable.LRem(ctx Context, key string, count int64, value interface{}) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.LSet(ctx Context, key string, index int64, value interface{}) *redis.StatusCmd func github.com/go-redis/redis/v8.Cmdable.LTrim(ctx Context, key string, start, stop int64) *redis.StatusCmd func github.com/go-redis/redis/v8.Cmdable.MemoryUsage(ctx Context, key string, samples ...int) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.MGet(ctx Context, keys ...string) *redis.SliceCmd func github.com/go-redis/redis/v8.Cmdable.Migrate(ctx Context, host, port, key string, db int, timeout time.Duration) *redis.StatusCmd func github.com/go-redis/redis/v8.Cmdable.Move(ctx Context, key string, db int) *redis.BoolCmd func github.com/go-redis/redis/v8.Cmdable.MSet(ctx Context, values ...interface{}) *redis.StatusCmd func github.com/go-redis/redis/v8.Cmdable.MSetNX(ctx Context, values ...interface{}) *redis.BoolCmd func github.com/go-redis/redis/v8.Cmdable.ObjectEncoding(ctx Context, key string) *redis.StringCmd func github.com/go-redis/redis/v8.Cmdable.ObjectIdleTime(ctx Context, key string) *redis.DurationCmd func github.com/go-redis/redis/v8.Cmdable.ObjectRefCount(ctx Context, key string) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.Persist(ctx Context, key string) *redis.BoolCmd func github.com/go-redis/redis/v8.Cmdable.PExpire(ctx Context, key string, expiration time.Duration) *redis.BoolCmd func github.com/go-redis/redis/v8.Cmdable.PExpireAt(ctx Context, key string, tm time.Time) *redis.BoolCmd func github.com/go-redis/redis/v8.Cmdable.PFAdd(ctx Context, key string, els ...interface{}) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.PFCount(ctx Context, keys ...string) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.PFMerge(ctx Context, dest string, keys ...string) *redis.StatusCmd func github.com/go-redis/redis/v8.Cmdable.Ping(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.Cmdable.Pipelined(ctx Context, fn func(redis.Pipeliner) error) ([]redis.Cmder, error) func github.com/go-redis/redis/v8.Cmdable.PTTL(ctx Context, key string) *redis.DurationCmd func github.com/go-redis/redis/v8.Cmdable.Publish(ctx Context, channel string, message interface{}) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.PubSubChannels(ctx Context, pattern string) *redis.StringSliceCmd func github.com/go-redis/redis/v8.Cmdable.PubSubNumPat(ctx Context) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.PubSubNumSub(ctx Context, channels ...string) *redis.StringIntMapCmd func github.com/go-redis/redis/v8.Cmdable.Quit(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.Cmdable.RandomKey(ctx Context) *redis.StringCmd func github.com/go-redis/redis/v8.Cmdable.ReadOnly(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.Cmdable.ReadWrite(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.Cmdable.Rename(ctx Context, key, newkey string) *redis.StatusCmd func github.com/go-redis/redis/v8.Cmdable.RenameNX(ctx Context, key, newkey string) *redis.BoolCmd func github.com/go-redis/redis/v8.Cmdable.Restore(ctx Context, key string, ttl time.Duration, value string) *redis.StatusCmd func github.com/go-redis/redis/v8.Cmdable.RestoreReplace(ctx Context, key string, ttl time.Duration, value string) *redis.StatusCmd func github.com/go-redis/redis/v8.Cmdable.RPop(ctx Context, key string) *redis.StringCmd func github.com/go-redis/redis/v8.Cmdable.RPopLPush(ctx Context, source, destination string) *redis.StringCmd func github.com/go-redis/redis/v8.Cmdable.RPush(ctx Context, key string, values ...interface{}) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.RPushX(ctx Context, key string, values ...interface{}) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.SAdd(ctx Context, key string, members ...interface{}) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.Save(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.Cmdable.Scan(ctx Context, cursor uint64, match string, count int64) *redis.ScanCmd func github.com/go-redis/redis/v8.Cmdable.SCard(ctx Context, key string) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.ScriptExists(ctx Context, hashes ...string) *redis.BoolSliceCmd func github.com/go-redis/redis/v8.Cmdable.ScriptFlush(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.Cmdable.ScriptKill(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.Cmdable.ScriptLoad(ctx Context, script string) *redis.StringCmd func github.com/go-redis/redis/v8.Cmdable.SDiff(ctx Context, keys ...string) *redis.StringSliceCmd func github.com/go-redis/redis/v8.Cmdable.SDiffStore(ctx Context, destination string, keys ...string) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.Set(ctx Context, key string, value interface{}, expiration time.Duration) *redis.StatusCmd func github.com/go-redis/redis/v8.Cmdable.SetBit(ctx Context, key string, offset int64, value int) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.SetNX(ctx Context, key string, value interface{}, expiration time.Duration) *redis.BoolCmd func github.com/go-redis/redis/v8.Cmdable.SetRange(ctx Context, key string, offset int64, value string) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.SetXX(ctx Context, key string, value interface{}, expiration time.Duration) *redis.BoolCmd func github.com/go-redis/redis/v8.Cmdable.Shutdown(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.Cmdable.ShutdownNoSave(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.Cmdable.ShutdownSave(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.Cmdable.SInter(ctx Context, keys ...string) *redis.StringSliceCmd func github.com/go-redis/redis/v8.Cmdable.SInterStore(ctx Context, destination string, keys ...string) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.SIsMember(ctx Context, key string, member interface{}) *redis.BoolCmd func github.com/go-redis/redis/v8.Cmdable.SlaveOf(ctx Context, host, port string) *redis.StatusCmd func github.com/go-redis/redis/v8.Cmdable.SMembers(ctx Context, key string) *redis.StringSliceCmd func github.com/go-redis/redis/v8.Cmdable.SMembersMap(ctx Context, key string) *redis.StringStructMapCmd func github.com/go-redis/redis/v8.Cmdable.SMove(ctx Context, source, destination string, member interface{}) *redis.BoolCmd func github.com/go-redis/redis/v8.Cmdable.Sort(ctx Context, key string, sort *redis.Sort) *redis.StringSliceCmd func github.com/go-redis/redis/v8.Cmdable.SortInterfaces(ctx Context, key string, sort *redis.Sort) *redis.SliceCmd func github.com/go-redis/redis/v8.Cmdable.SortStore(ctx Context, key, store string, sort *redis.Sort) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.SPop(ctx Context, key string) *redis.StringCmd func github.com/go-redis/redis/v8.Cmdable.SPopN(ctx Context, key string, count int64) *redis.StringSliceCmd func github.com/go-redis/redis/v8.Cmdable.SRandMember(ctx Context, key string) *redis.StringCmd func github.com/go-redis/redis/v8.Cmdable.SRandMemberN(ctx Context, key string, count int64) *redis.StringSliceCmd func github.com/go-redis/redis/v8.Cmdable.SRem(ctx Context, key string, members ...interface{}) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.SScan(ctx Context, key string, cursor uint64, match string, count int64) *redis.ScanCmd func github.com/go-redis/redis/v8.Cmdable.StrLen(ctx Context, key string) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.SUnion(ctx Context, keys ...string) *redis.StringSliceCmd func github.com/go-redis/redis/v8.Cmdable.SUnionStore(ctx Context, destination string, keys ...string) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.Time(ctx Context) *redis.TimeCmd func github.com/go-redis/redis/v8.Cmdable.Touch(ctx Context, keys ...string) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.TTL(ctx Context, key string) *redis.DurationCmd func github.com/go-redis/redis/v8.Cmdable.TxPipelined(ctx Context, fn func(redis.Pipeliner) error) ([]redis.Cmder, error) func github.com/go-redis/redis/v8.Cmdable.Type(ctx Context, key string) *redis.StatusCmd func github.com/go-redis/redis/v8.Cmdable.Unlink(ctx Context, keys ...string) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.XAck(ctx Context, stream, group string, ids ...string) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.XAdd(ctx Context, a *redis.XAddArgs) *redis.StringCmd func github.com/go-redis/redis/v8.Cmdable.XClaim(ctx Context, a *redis.XClaimArgs) *redis.XMessageSliceCmd func github.com/go-redis/redis/v8.Cmdable.XClaimJustID(ctx Context, a *redis.XClaimArgs) *redis.StringSliceCmd func github.com/go-redis/redis/v8.Cmdable.XDel(ctx Context, stream string, ids ...string) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.XGroupCreate(ctx Context, stream, group, start string) *redis.StatusCmd func github.com/go-redis/redis/v8.Cmdable.XGroupCreateMkStream(ctx Context, stream, group, start string) *redis.StatusCmd func github.com/go-redis/redis/v8.Cmdable.XGroupDelConsumer(ctx Context, stream, group, consumer string) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.XGroupDestroy(ctx Context, stream, group string) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.XGroupSetID(ctx Context, stream, group, start string) *redis.StatusCmd func github.com/go-redis/redis/v8.Cmdable.XInfoGroups(ctx Context, key string) *redis.XInfoGroupsCmd func github.com/go-redis/redis/v8.Cmdable.XLen(ctx Context, stream string) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.XPending(ctx Context, stream, group string) *redis.XPendingCmd func github.com/go-redis/redis/v8.Cmdable.XPendingExt(ctx Context, a *redis.XPendingExtArgs) *redis.XPendingExtCmd func github.com/go-redis/redis/v8.Cmdable.XRange(ctx Context, stream, start, stop string) *redis.XMessageSliceCmd func github.com/go-redis/redis/v8.Cmdable.XRangeN(ctx Context, stream, start, stop string, count int64) *redis.XMessageSliceCmd func github.com/go-redis/redis/v8.Cmdable.XRead(ctx Context, a *redis.XReadArgs) *redis.XStreamSliceCmd func github.com/go-redis/redis/v8.Cmdable.XReadGroup(ctx Context, a *redis.XReadGroupArgs) *redis.XStreamSliceCmd func github.com/go-redis/redis/v8.Cmdable.XReadStreams(ctx Context, streams ...string) *redis.XStreamSliceCmd func github.com/go-redis/redis/v8.Cmdable.XRevRange(ctx Context, stream string, start, stop string) *redis.XMessageSliceCmd func github.com/go-redis/redis/v8.Cmdable.XRevRangeN(ctx Context, stream string, start, stop string, count int64) *redis.XMessageSliceCmd func github.com/go-redis/redis/v8.Cmdable.XTrim(ctx Context, key string, maxLen int64) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.XTrimApprox(ctx Context, key string, maxLen int64) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.ZAdd(ctx Context, key string, members ...*redis.Z) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.ZAddCh(ctx Context, key string, members ...*redis.Z) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.ZAddNX(ctx Context, key string, members ...*redis.Z) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.ZAddNXCh(ctx Context, key string, members ...*redis.Z) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.ZAddXX(ctx Context, key string, members ...*redis.Z) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.ZAddXXCh(ctx Context, key string, members ...*redis.Z) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.ZCard(ctx Context, key string) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.ZCount(ctx Context, key, min, max string) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.ZIncr(ctx Context, key string, member *redis.Z) *redis.FloatCmd func github.com/go-redis/redis/v8.Cmdable.ZIncrBy(ctx Context, key string, increment float64, member string) *redis.FloatCmd func github.com/go-redis/redis/v8.Cmdable.ZIncrNX(ctx Context, key string, member *redis.Z) *redis.FloatCmd func github.com/go-redis/redis/v8.Cmdable.ZIncrXX(ctx Context, key string, member *redis.Z) *redis.FloatCmd func github.com/go-redis/redis/v8.Cmdable.ZInterStore(ctx Context, destination string, store *redis.ZStore) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.ZLexCount(ctx Context, key, min, max string) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.ZPopMax(ctx Context, key string, count ...int64) *redis.ZSliceCmd func github.com/go-redis/redis/v8.Cmdable.ZPopMin(ctx Context, key string, count ...int64) *redis.ZSliceCmd func github.com/go-redis/redis/v8.Cmdable.ZRange(ctx Context, key string, start, stop int64) *redis.StringSliceCmd func github.com/go-redis/redis/v8.Cmdable.ZRangeByLex(ctx Context, key string, opt *redis.ZRangeBy) *redis.StringSliceCmd func github.com/go-redis/redis/v8.Cmdable.ZRangeByScore(ctx Context, key string, opt *redis.ZRangeBy) *redis.StringSliceCmd func github.com/go-redis/redis/v8.Cmdable.ZRangeByScoreWithScores(ctx Context, key string, opt *redis.ZRangeBy) *redis.ZSliceCmd func github.com/go-redis/redis/v8.Cmdable.ZRangeWithScores(ctx Context, key string, start, stop int64) *redis.ZSliceCmd func github.com/go-redis/redis/v8.Cmdable.ZRank(ctx Context, key, member string) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.ZRem(ctx Context, key string, members ...interface{}) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.ZRemRangeByLex(ctx Context, key, min, max string) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.ZRemRangeByRank(ctx Context, key string, start, stop int64) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.ZRemRangeByScore(ctx Context, key, min, max string) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.ZRevRange(ctx Context, key string, start, stop int64) *redis.StringSliceCmd func github.com/go-redis/redis/v8.Cmdable.ZRevRangeByLex(ctx Context, key string, opt *redis.ZRangeBy) *redis.StringSliceCmd func github.com/go-redis/redis/v8.Cmdable.ZRevRangeByScore(ctx Context, key string, opt *redis.ZRangeBy) *redis.StringSliceCmd func github.com/go-redis/redis/v8.Cmdable.ZRevRangeByScoreWithScores(ctx Context, key string, opt *redis.ZRangeBy) *redis.ZSliceCmd func github.com/go-redis/redis/v8.Cmdable.ZRevRangeWithScores(ctx Context, key string, start, stop int64) *redis.ZSliceCmd func github.com/go-redis/redis/v8.Cmdable.ZRevRank(ctx Context, key, member string) *redis.IntCmd func github.com/go-redis/redis/v8.Cmdable.ZScan(ctx Context, key string, cursor uint64, match string, count int64) *redis.ScanCmd func github.com/go-redis/redis/v8.Cmdable.ZScore(ctx Context, key, member string) *redis.FloatCmd func github.com/go-redis/redis/v8.Cmdable.ZUnionStore(ctx Context, dest string, store *redis.ZStore) *redis.IntCmd func github.com/go-redis/redis/v8.(*Conn).Pipelined(ctx Context, fn func(redis.Pipeliner) error) ([]redis.Cmder, error) func github.com/go-redis/redis/v8.(*Conn).Process(ctx Context, cmd redis.Cmder) error func github.com/go-redis/redis/v8.(*Conn).TxPipelined(ctx Context, fn func(redis.Pipeliner) error) ([]redis.Cmder, error) func github.com/go-redis/redis/v8.Hook.AfterProcess(ctx Context, cmd redis.Cmder) error func github.com/go-redis/redis/v8.Hook.AfterProcessPipeline(ctx Context, cmds []redis.Cmder) error func github.com/go-redis/redis/v8.Hook.BeforeProcess(ctx Context, cmd redis.Cmder) (Context, error) func github.com/go-redis/redis/v8.Hook.BeforeProcessPipeline(ctx Context, cmds []redis.Cmder) (Context, error) func github.com/go-redis/redis/v8.(*Pipeline).Do(ctx Context, args ...interface{}) *redis.Cmd func github.com/go-redis/redis/v8.(*Pipeline).Exec(ctx Context) ([]redis.Cmder, error) func github.com/go-redis/redis/v8.(*Pipeline).Pipelined(ctx Context, fn func(redis.Pipeliner) error) ([]redis.Cmder, error) func github.com/go-redis/redis/v8.(*Pipeline).Process(ctx Context, cmd redis.Cmder) error func github.com/go-redis/redis/v8.(*Pipeline).TxPipelined(ctx Context, fn func(redis.Pipeliner) error) ([]redis.Cmder, error) func github.com/go-redis/redis/v8.Pipeliner.Append(ctx Context, key, value string) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.Auth(ctx Context, password string) *redis.StatusCmd func github.com/go-redis/redis/v8.Pipeliner.AuthACL(ctx Context, username, password string) *redis.StatusCmd func github.com/go-redis/redis/v8.Pipeliner.BgRewriteAOF(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.Pipeliner.BgSave(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.Pipeliner.BitCount(ctx Context, key string, bitCount *redis.BitCount) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.BitField(ctx Context, key string, args ...interface{}) *redis.IntSliceCmd func github.com/go-redis/redis/v8.Pipeliner.BitOpAnd(ctx Context, destKey string, keys ...string) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.BitOpNot(ctx Context, destKey string, key string) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.BitOpOr(ctx Context, destKey string, keys ...string) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.BitOpXor(ctx Context, destKey string, keys ...string) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.BitPos(ctx Context, key string, bit int64, pos ...int64) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.BLPop(ctx Context, timeout time.Duration, keys ...string) *redis.StringSliceCmd func github.com/go-redis/redis/v8.Pipeliner.BRPop(ctx Context, timeout time.Duration, keys ...string) *redis.StringSliceCmd func github.com/go-redis/redis/v8.Pipeliner.BRPopLPush(ctx Context, source, destination string, timeout time.Duration) *redis.StringCmd func github.com/go-redis/redis/v8.Pipeliner.BZPopMax(ctx Context, timeout time.Duration, keys ...string) *redis.ZWithKeyCmd func github.com/go-redis/redis/v8.Pipeliner.BZPopMin(ctx Context, timeout time.Duration, keys ...string) *redis.ZWithKeyCmd func github.com/go-redis/redis/v8.Pipeliner.ClientGetName(ctx Context) *redis.StringCmd func github.com/go-redis/redis/v8.Pipeliner.ClientID(ctx Context) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.ClientKill(ctx Context, ipPort string) *redis.StatusCmd func github.com/go-redis/redis/v8.Pipeliner.ClientKillByFilter(ctx Context, keys ...string) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.ClientList(ctx Context) *redis.StringCmd func github.com/go-redis/redis/v8.Pipeliner.ClientPause(ctx Context, dur time.Duration) *redis.BoolCmd func github.com/go-redis/redis/v8.Pipeliner.ClientSetName(ctx Context, name string) *redis.BoolCmd func github.com/go-redis/redis/v8.Pipeliner.ClusterAddSlots(ctx Context, slots ...int) *redis.StatusCmd func github.com/go-redis/redis/v8.Pipeliner.ClusterAddSlotsRange(ctx Context, min, max int) *redis.StatusCmd func github.com/go-redis/redis/v8.Pipeliner.ClusterCountFailureReports(ctx Context, nodeID string) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.ClusterCountKeysInSlot(ctx Context, slot int) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.ClusterDelSlots(ctx Context, slots ...int) *redis.StatusCmd func github.com/go-redis/redis/v8.Pipeliner.ClusterDelSlotsRange(ctx Context, min, max int) *redis.StatusCmd func github.com/go-redis/redis/v8.Pipeliner.ClusterFailover(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.Pipeliner.ClusterForget(ctx Context, nodeID string) *redis.StatusCmd func github.com/go-redis/redis/v8.Pipeliner.ClusterGetKeysInSlot(ctx Context, slot int, count int) *redis.StringSliceCmd func github.com/go-redis/redis/v8.Pipeliner.ClusterInfo(ctx Context) *redis.StringCmd func github.com/go-redis/redis/v8.Pipeliner.ClusterKeySlot(ctx Context, key string) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.ClusterMeet(ctx Context, host, port string) *redis.StatusCmd func github.com/go-redis/redis/v8.Pipeliner.ClusterNodes(ctx Context) *redis.StringCmd func github.com/go-redis/redis/v8.Pipeliner.ClusterReplicate(ctx Context, nodeID string) *redis.StatusCmd func github.com/go-redis/redis/v8.Pipeliner.ClusterResetHard(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.Pipeliner.ClusterResetSoft(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.Pipeliner.ClusterSaveConfig(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.Pipeliner.ClusterSlaves(ctx Context, nodeID string) *redis.StringSliceCmd func github.com/go-redis/redis/v8.Pipeliner.ClusterSlots(ctx Context) *redis.ClusterSlotsCmd func github.com/go-redis/redis/v8.Pipeliner.Command(ctx Context) *redis.CommandsInfoCmd func github.com/go-redis/redis/v8.Pipeliner.ConfigGet(ctx Context, parameter string) *redis.SliceCmd func github.com/go-redis/redis/v8.Pipeliner.ConfigResetStat(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.Pipeliner.ConfigRewrite(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.Pipeliner.ConfigSet(ctx Context, parameter, value string) *redis.StatusCmd func github.com/go-redis/redis/v8.Pipeliner.DBSize(ctx Context) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.DebugObject(ctx Context, key string) *redis.StringCmd func github.com/go-redis/redis/v8.Pipeliner.Decr(ctx Context, key string) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.DecrBy(ctx Context, key string, decrement int64) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.Del(ctx Context, keys ...string) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.Do(ctx Context, args ...interface{}) *redis.Cmd func github.com/go-redis/redis/v8.Pipeliner.Dump(ctx Context, key string) *redis.StringCmd func github.com/go-redis/redis/v8.Pipeliner.Echo(ctx Context, message interface{}) *redis.StringCmd func github.com/go-redis/redis/v8.Pipeliner.Eval(ctx Context, script string, keys []string, args ...interface{}) *redis.Cmd func github.com/go-redis/redis/v8.Pipeliner.EvalSha(ctx Context, sha1 string, keys []string, args ...interface{}) *redis.Cmd func github.com/go-redis/redis/v8.Pipeliner.Exec(ctx Context) ([]redis.Cmder, error) func github.com/go-redis/redis/v8.Pipeliner.Exists(ctx Context, keys ...string) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.Expire(ctx Context, key string, expiration time.Duration) *redis.BoolCmd func github.com/go-redis/redis/v8.Pipeliner.ExpireAt(ctx Context, key string, tm time.Time) *redis.BoolCmd func github.com/go-redis/redis/v8.Pipeliner.FlushAll(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.Pipeliner.FlushAllAsync(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.Pipeliner.FlushDB(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.Pipeliner.FlushDBAsync(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.Pipeliner.GeoAdd(ctx Context, key string, geoLocation ...*redis.GeoLocation) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.GeoDist(ctx Context, key string, member1, member2, unit string) *redis.FloatCmd func github.com/go-redis/redis/v8.Pipeliner.GeoHash(ctx Context, key string, members ...string) *redis.StringSliceCmd func github.com/go-redis/redis/v8.Pipeliner.GeoPos(ctx Context, key string, members ...string) *redis.GeoPosCmd func github.com/go-redis/redis/v8.Pipeliner.GeoRadius(ctx Context, key string, longitude, latitude float64, query *redis.GeoRadiusQuery) *redis.GeoLocationCmd func github.com/go-redis/redis/v8.Pipeliner.GeoRadiusByMember(ctx Context, key, member string, query *redis.GeoRadiusQuery) *redis.GeoLocationCmd func github.com/go-redis/redis/v8.Pipeliner.GeoRadiusByMemberStore(ctx Context, key, member string, query *redis.GeoRadiusQuery) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.GeoRadiusStore(ctx Context, key string, longitude, latitude float64, query *redis.GeoRadiusQuery) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.Get(ctx Context, key string) *redis.StringCmd func github.com/go-redis/redis/v8.Pipeliner.GetBit(ctx Context, key string, offset int64) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.GetRange(ctx Context, key string, start, end int64) *redis.StringCmd func github.com/go-redis/redis/v8.Pipeliner.GetSet(ctx Context, key string, value interface{}) *redis.StringCmd func github.com/go-redis/redis/v8.Pipeliner.HDel(ctx Context, key string, fields ...string) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.HExists(ctx Context, key, field string) *redis.BoolCmd func github.com/go-redis/redis/v8.Pipeliner.HGet(ctx Context, key, field string) *redis.StringCmd func github.com/go-redis/redis/v8.Pipeliner.HGetAll(ctx Context, key string) *redis.StringStringMapCmd func github.com/go-redis/redis/v8.Pipeliner.HIncrBy(ctx Context, key, field string, incr int64) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.HIncrByFloat(ctx Context, key, field string, incr float64) *redis.FloatCmd func github.com/go-redis/redis/v8.Pipeliner.HKeys(ctx Context, key string) *redis.StringSliceCmd func github.com/go-redis/redis/v8.Pipeliner.HLen(ctx Context, key string) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.HMGet(ctx Context, key string, fields ...string) *redis.SliceCmd func github.com/go-redis/redis/v8.Pipeliner.HMSet(ctx Context, key string, values ...interface{}) *redis.BoolCmd func github.com/go-redis/redis/v8.Pipeliner.HScan(ctx Context, key string, cursor uint64, match string, count int64) *redis.ScanCmd func github.com/go-redis/redis/v8.Pipeliner.HSet(ctx Context, key string, values ...interface{}) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.HSetNX(ctx Context, key, field string, value interface{}) *redis.BoolCmd func github.com/go-redis/redis/v8.Pipeliner.HVals(ctx Context, key string) *redis.StringSliceCmd func github.com/go-redis/redis/v8.Pipeliner.Incr(ctx Context, key string) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.IncrBy(ctx Context, key string, value int64) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.IncrByFloat(ctx Context, key string, value float64) *redis.FloatCmd func github.com/go-redis/redis/v8.Pipeliner.Info(ctx Context, section ...string) *redis.StringCmd func github.com/go-redis/redis/v8.Pipeliner.Keys(ctx Context, pattern string) *redis.StringSliceCmd func github.com/go-redis/redis/v8.Pipeliner.LastSave(ctx Context) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.LIndex(ctx Context, key string, index int64) *redis.StringCmd func github.com/go-redis/redis/v8.Pipeliner.LInsert(ctx Context, key, op string, pivot, value interface{}) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.LInsertAfter(ctx Context, key string, pivot, value interface{}) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.LInsertBefore(ctx Context, key string, pivot, value interface{}) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.LLen(ctx Context, key string) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.LPop(ctx Context, key string) *redis.StringCmd func github.com/go-redis/redis/v8.Pipeliner.LPush(ctx Context, key string, values ...interface{}) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.LPushX(ctx Context, key string, values ...interface{}) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.LRange(ctx Context, key string, start, stop int64) *redis.StringSliceCmd func github.com/go-redis/redis/v8.Pipeliner.LRem(ctx Context, key string, count int64, value interface{}) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.LSet(ctx Context, key string, index int64, value interface{}) *redis.StatusCmd func github.com/go-redis/redis/v8.Pipeliner.LTrim(ctx Context, key string, start, stop int64) *redis.StatusCmd func github.com/go-redis/redis/v8.Pipeliner.MemoryUsage(ctx Context, key string, samples ...int) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.MGet(ctx Context, keys ...string) *redis.SliceCmd func github.com/go-redis/redis/v8.Pipeliner.Migrate(ctx Context, host, port, key string, db int, timeout time.Duration) *redis.StatusCmd func github.com/go-redis/redis/v8.Pipeliner.Move(ctx Context, key string, db int) *redis.BoolCmd func github.com/go-redis/redis/v8.Pipeliner.MSet(ctx Context, values ...interface{}) *redis.StatusCmd func github.com/go-redis/redis/v8.Pipeliner.MSetNX(ctx Context, values ...interface{}) *redis.BoolCmd func github.com/go-redis/redis/v8.Pipeliner.ObjectEncoding(ctx Context, key string) *redis.StringCmd func github.com/go-redis/redis/v8.Pipeliner.ObjectIdleTime(ctx Context, key string) *redis.DurationCmd func github.com/go-redis/redis/v8.Pipeliner.ObjectRefCount(ctx Context, key string) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.Persist(ctx Context, key string) *redis.BoolCmd func github.com/go-redis/redis/v8.Pipeliner.PExpire(ctx Context, key string, expiration time.Duration) *redis.BoolCmd func github.com/go-redis/redis/v8.Pipeliner.PExpireAt(ctx Context, key string, tm time.Time) *redis.BoolCmd func github.com/go-redis/redis/v8.Pipeliner.PFAdd(ctx Context, key string, els ...interface{}) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.PFCount(ctx Context, keys ...string) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.PFMerge(ctx Context, dest string, keys ...string) *redis.StatusCmd func github.com/go-redis/redis/v8.Pipeliner.Ping(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.Pipeliner.Pipelined(ctx Context, fn func(redis.Pipeliner) error) ([]redis.Cmder, error) func github.com/go-redis/redis/v8.Pipeliner.Process(ctx Context, cmd redis.Cmder) error func github.com/go-redis/redis/v8.Pipeliner.PTTL(ctx Context, key string) *redis.DurationCmd func github.com/go-redis/redis/v8.Pipeliner.Publish(ctx Context, channel string, message interface{}) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.PubSubChannels(ctx Context, pattern string) *redis.StringSliceCmd func github.com/go-redis/redis/v8.Pipeliner.PubSubNumPat(ctx Context) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.PubSubNumSub(ctx Context, channels ...string) *redis.StringIntMapCmd func github.com/go-redis/redis/v8.Pipeliner.Quit(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.Pipeliner.RandomKey(ctx Context) *redis.StringCmd func github.com/go-redis/redis/v8.Pipeliner.ReadOnly(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.Pipeliner.ReadWrite(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.Pipeliner.Rename(ctx Context, key, newkey string) *redis.StatusCmd func github.com/go-redis/redis/v8.Pipeliner.RenameNX(ctx Context, key, newkey string) *redis.BoolCmd func github.com/go-redis/redis/v8.Pipeliner.Restore(ctx Context, key string, ttl time.Duration, value string) *redis.StatusCmd func github.com/go-redis/redis/v8.Pipeliner.RestoreReplace(ctx Context, key string, ttl time.Duration, value string) *redis.StatusCmd func github.com/go-redis/redis/v8.Pipeliner.RPop(ctx Context, key string) *redis.StringCmd func github.com/go-redis/redis/v8.Pipeliner.RPopLPush(ctx Context, source, destination string) *redis.StringCmd func github.com/go-redis/redis/v8.Pipeliner.RPush(ctx Context, key string, values ...interface{}) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.RPushX(ctx Context, key string, values ...interface{}) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.SAdd(ctx Context, key string, members ...interface{}) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.Save(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.Pipeliner.Scan(ctx Context, cursor uint64, match string, count int64) *redis.ScanCmd func github.com/go-redis/redis/v8.Pipeliner.SCard(ctx Context, key string) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.ScriptExists(ctx Context, hashes ...string) *redis.BoolSliceCmd func github.com/go-redis/redis/v8.Pipeliner.ScriptFlush(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.Pipeliner.ScriptKill(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.Pipeliner.ScriptLoad(ctx Context, script string) *redis.StringCmd func github.com/go-redis/redis/v8.Pipeliner.SDiff(ctx Context, keys ...string) *redis.StringSliceCmd func github.com/go-redis/redis/v8.Pipeliner.SDiffStore(ctx Context, destination string, keys ...string) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.Select(ctx Context, index int) *redis.StatusCmd func github.com/go-redis/redis/v8.Pipeliner.Set(ctx Context, key string, value interface{}, expiration time.Duration) *redis.StatusCmd func github.com/go-redis/redis/v8.Pipeliner.SetBit(ctx Context, key string, offset int64, value int) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.SetNX(ctx Context, key string, value interface{}, expiration time.Duration) *redis.BoolCmd func github.com/go-redis/redis/v8.Pipeliner.SetRange(ctx Context, key string, offset int64, value string) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.SetXX(ctx Context, key string, value interface{}, expiration time.Duration) *redis.BoolCmd func github.com/go-redis/redis/v8.Pipeliner.Shutdown(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.Pipeliner.ShutdownNoSave(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.Pipeliner.ShutdownSave(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.Pipeliner.SInter(ctx Context, keys ...string) *redis.StringSliceCmd func github.com/go-redis/redis/v8.Pipeliner.SInterStore(ctx Context, destination string, keys ...string) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.SIsMember(ctx Context, key string, member interface{}) *redis.BoolCmd func github.com/go-redis/redis/v8.Pipeliner.SlaveOf(ctx Context, host, port string) *redis.StatusCmd func github.com/go-redis/redis/v8.Pipeliner.SMembers(ctx Context, key string) *redis.StringSliceCmd func github.com/go-redis/redis/v8.Pipeliner.SMembersMap(ctx Context, key string) *redis.StringStructMapCmd func github.com/go-redis/redis/v8.Pipeliner.SMove(ctx Context, source, destination string, member interface{}) *redis.BoolCmd func github.com/go-redis/redis/v8.Pipeliner.Sort(ctx Context, key string, sort *redis.Sort) *redis.StringSliceCmd func github.com/go-redis/redis/v8.Pipeliner.SortInterfaces(ctx Context, key string, sort *redis.Sort) *redis.SliceCmd func github.com/go-redis/redis/v8.Pipeliner.SortStore(ctx Context, key, store string, sort *redis.Sort) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.SPop(ctx Context, key string) *redis.StringCmd func github.com/go-redis/redis/v8.Pipeliner.SPopN(ctx Context, key string, count int64) *redis.StringSliceCmd func github.com/go-redis/redis/v8.Pipeliner.SRandMember(ctx Context, key string) *redis.StringCmd func github.com/go-redis/redis/v8.Pipeliner.SRandMemberN(ctx Context, key string, count int64) *redis.StringSliceCmd func github.com/go-redis/redis/v8.Pipeliner.SRem(ctx Context, key string, members ...interface{}) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.SScan(ctx Context, key string, cursor uint64, match string, count int64) *redis.ScanCmd func github.com/go-redis/redis/v8.Pipeliner.StrLen(ctx Context, key string) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.SUnion(ctx Context, keys ...string) *redis.StringSliceCmd func github.com/go-redis/redis/v8.Pipeliner.SUnionStore(ctx Context, destination string, keys ...string) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.SwapDB(ctx Context, index1, index2 int) *redis.StatusCmd func github.com/go-redis/redis/v8.Pipeliner.Time(ctx Context) *redis.TimeCmd func github.com/go-redis/redis/v8.Pipeliner.Touch(ctx Context, keys ...string) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.TTL(ctx Context, key string) *redis.DurationCmd func github.com/go-redis/redis/v8.Pipeliner.TxPipelined(ctx Context, fn func(redis.Pipeliner) error) ([]redis.Cmder, error) func github.com/go-redis/redis/v8.Pipeliner.Type(ctx Context, key string) *redis.StatusCmd func github.com/go-redis/redis/v8.Pipeliner.Unlink(ctx Context, keys ...string) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.XAck(ctx Context, stream, group string, ids ...string) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.XAdd(ctx Context, a *redis.XAddArgs) *redis.StringCmd func github.com/go-redis/redis/v8.Pipeliner.XClaim(ctx Context, a *redis.XClaimArgs) *redis.XMessageSliceCmd func github.com/go-redis/redis/v8.Pipeliner.XClaimJustID(ctx Context, a *redis.XClaimArgs) *redis.StringSliceCmd func github.com/go-redis/redis/v8.Pipeliner.XDel(ctx Context, stream string, ids ...string) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.XGroupCreate(ctx Context, stream, group, start string) *redis.StatusCmd func github.com/go-redis/redis/v8.Pipeliner.XGroupCreateMkStream(ctx Context, stream, group, start string) *redis.StatusCmd func github.com/go-redis/redis/v8.Pipeliner.XGroupDelConsumer(ctx Context, stream, group, consumer string) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.XGroupDestroy(ctx Context, stream, group string) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.XGroupSetID(ctx Context, stream, group, start string) *redis.StatusCmd func github.com/go-redis/redis/v8.Pipeliner.XInfoGroups(ctx Context, key string) *redis.XInfoGroupsCmd func github.com/go-redis/redis/v8.Pipeliner.XLen(ctx Context, stream string) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.XPending(ctx Context, stream, group string) *redis.XPendingCmd func github.com/go-redis/redis/v8.Pipeliner.XPendingExt(ctx Context, a *redis.XPendingExtArgs) *redis.XPendingExtCmd func github.com/go-redis/redis/v8.Pipeliner.XRange(ctx Context, stream, start, stop string) *redis.XMessageSliceCmd func github.com/go-redis/redis/v8.Pipeliner.XRangeN(ctx Context, stream, start, stop string, count int64) *redis.XMessageSliceCmd func github.com/go-redis/redis/v8.Pipeliner.XRead(ctx Context, a *redis.XReadArgs) *redis.XStreamSliceCmd func github.com/go-redis/redis/v8.Pipeliner.XReadGroup(ctx Context, a *redis.XReadGroupArgs) *redis.XStreamSliceCmd func github.com/go-redis/redis/v8.Pipeliner.XReadStreams(ctx Context, streams ...string) *redis.XStreamSliceCmd func github.com/go-redis/redis/v8.Pipeliner.XRevRange(ctx Context, stream string, start, stop string) *redis.XMessageSliceCmd func github.com/go-redis/redis/v8.Pipeliner.XRevRangeN(ctx Context, stream string, start, stop string, count int64) *redis.XMessageSliceCmd func github.com/go-redis/redis/v8.Pipeliner.XTrim(ctx Context, key string, maxLen int64) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.XTrimApprox(ctx Context, key string, maxLen int64) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.ZAdd(ctx Context, key string, members ...*redis.Z) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.ZAddCh(ctx Context, key string, members ...*redis.Z) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.ZAddNX(ctx Context, key string, members ...*redis.Z) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.ZAddNXCh(ctx Context, key string, members ...*redis.Z) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.ZAddXX(ctx Context, key string, members ...*redis.Z) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.ZAddXXCh(ctx Context, key string, members ...*redis.Z) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.ZCard(ctx Context, key string) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.ZCount(ctx Context, key, min, max string) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.ZIncr(ctx Context, key string, member *redis.Z) *redis.FloatCmd func github.com/go-redis/redis/v8.Pipeliner.ZIncrBy(ctx Context, key string, increment float64, member string) *redis.FloatCmd func github.com/go-redis/redis/v8.Pipeliner.ZIncrNX(ctx Context, key string, member *redis.Z) *redis.FloatCmd func github.com/go-redis/redis/v8.Pipeliner.ZIncrXX(ctx Context, key string, member *redis.Z) *redis.FloatCmd func github.com/go-redis/redis/v8.Pipeliner.ZInterStore(ctx Context, destination string, store *redis.ZStore) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.ZLexCount(ctx Context, key, min, max string) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.ZPopMax(ctx Context, key string, count ...int64) *redis.ZSliceCmd func github.com/go-redis/redis/v8.Pipeliner.ZPopMin(ctx Context, key string, count ...int64) *redis.ZSliceCmd func github.com/go-redis/redis/v8.Pipeliner.ZRange(ctx Context, key string, start, stop int64) *redis.StringSliceCmd func github.com/go-redis/redis/v8.Pipeliner.ZRangeByLex(ctx Context, key string, opt *redis.ZRangeBy) *redis.StringSliceCmd func github.com/go-redis/redis/v8.Pipeliner.ZRangeByScore(ctx Context, key string, opt *redis.ZRangeBy) *redis.StringSliceCmd func github.com/go-redis/redis/v8.Pipeliner.ZRangeByScoreWithScores(ctx Context, key string, opt *redis.ZRangeBy) *redis.ZSliceCmd func github.com/go-redis/redis/v8.Pipeliner.ZRangeWithScores(ctx Context, key string, start, stop int64) *redis.ZSliceCmd func github.com/go-redis/redis/v8.Pipeliner.ZRank(ctx Context, key, member string) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.ZRem(ctx Context, key string, members ...interface{}) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.ZRemRangeByLex(ctx Context, key, min, max string) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.ZRemRangeByRank(ctx Context, key string, start, stop int64) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.ZRemRangeByScore(ctx Context, key, min, max string) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.ZRevRange(ctx Context, key string, start, stop int64) *redis.StringSliceCmd func github.com/go-redis/redis/v8.Pipeliner.ZRevRangeByLex(ctx Context, key string, opt *redis.ZRangeBy) *redis.StringSliceCmd func github.com/go-redis/redis/v8.Pipeliner.ZRevRangeByScore(ctx Context, key string, opt *redis.ZRangeBy) *redis.StringSliceCmd func github.com/go-redis/redis/v8.Pipeliner.ZRevRangeByScoreWithScores(ctx Context, key string, opt *redis.ZRangeBy) *redis.ZSliceCmd func github.com/go-redis/redis/v8.Pipeliner.ZRevRangeWithScores(ctx Context, key string, start, stop int64) *redis.ZSliceCmd func github.com/go-redis/redis/v8.Pipeliner.ZRevRank(ctx Context, key, member string) *redis.IntCmd func github.com/go-redis/redis/v8.Pipeliner.ZScan(ctx Context, key string, cursor uint64, match string, count int64) *redis.ScanCmd func github.com/go-redis/redis/v8.Pipeliner.ZScore(ctx Context, key, member string) *redis.FloatCmd func github.com/go-redis/redis/v8.Pipeliner.ZUnionStore(ctx Context, dest string, store *redis.ZStore) *redis.IntCmd func github.com/go-redis/redis/v8.(*PubSub).ChannelWithSubscriptions(ctx Context, size int) <-chan interface{} func github.com/go-redis/redis/v8.(*PubSub).Ping(ctx Context, payload ...string) error func github.com/go-redis/redis/v8.(*PubSub).PSubscribe(ctx Context, patterns ...string) error func github.com/go-redis/redis/v8.(*PubSub).PUnsubscribe(ctx Context, patterns ...string) error func github.com/go-redis/redis/v8.(*PubSub).Receive(ctx Context) (interface{}, error) func github.com/go-redis/redis/v8.(*PubSub).ReceiveMessage(ctx Context) (*redis.Message, error) func github.com/go-redis/redis/v8.(*PubSub).ReceiveTimeout(ctx Context, timeout time.Duration) (interface{}, error) func github.com/go-redis/redis/v8.(*PubSub).Subscribe(ctx Context, channels ...string) error func github.com/go-redis/redis/v8.(*PubSub).Unsubscribe(ctx Context, channels ...string) error func github.com/go-redis/redis/v8.(*Ring).Do(ctx Context, args ...interface{}) *redis.Cmd func github.com/go-redis/redis/v8.(*Ring).ForEachShard(ctx Context, fn func(ctx Context, client *redis.Client) error) error func github.com/go-redis/redis/v8.(*Ring).Pipelined(ctx Context, fn func(redis.Pipeliner) error) ([]redis.Cmder, error) func github.com/go-redis/redis/v8.(*Ring).Process(ctx Context, cmd redis.Cmder) error func github.com/go-redis/redis/v8.(*Ring).PSubscribe(ctx Context, channels ...string) *redis.PubSub func github.com/go-redis/redis/v8.(*Ring).Subscribe(ctx Context, channels ...string) *redis.PubSub func github.com/go-redis/redis/v8.(*Ring).TxPipelined(ctx Context, fn func(redis.Pipeliner) error) ([]redis.Cmder, error) func github.com/go-redis/redis/v8.(*Ring).Watch(ctx Context, fn func(*redis.Tx) error, keys ...string) error func github.com/go-redis/redis/v8.(*Ring).WithContext(ctx Context) *redis.Ring func github.com/go-redis/redis/v8.(*ScanIterator).Next(ctx Context) bool func github.com/go-redis/redis/v8.(*Script).Eval(ctx Context, c redis.scripter, keys []string, args ...interface{}) *redis.Cmd func github.com/go-redis/redis/v8.(*Script).EvalSha(ctx Context, c redis.scripter, keys []string, args ...interface{}) *redis.Cmd func github.com/go-redis/redis/v8.(*Script).Exists(ctx Context, c redis.scripter) *redis.BoolSliceCmd func github.com/go-redis/redis/v8.(*Script).Load(ctx Context, c redis.scripter) *redis.StringCmd func github.com/go-redis/redis/v8.(*Script).Run(ctx Context, c redis.scripter, keys []string, args ...interface{}) *redis.Cmd func github.com/go-redis/redis/v8.(*SentinelClient).CkQuorum(ctx Context, name string) *redis.StringCmd func github.com/go-redis/redis/v8.(*SentinelClient).Failover(ctx Context, name string) *redis.StatusCmd func github.com/go-redis/redis/v8.(*SentinelClient).FlushConfig(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.(*SentinelClient).GetMasterAddrByName(ctx Context, name string) *redis.StringSliceCmd func github.com/go-redis/redis/v8.(*SentinelClient).Master(ctx Context, name string) *redis.StringStringMapCmd func github.com/go-redis/redis/v8.(*SentinelClient).Masters(ctx Context) *redis.SliceCmd func github.com/go-redis/redis/v8.(*SentinelClient).Monitor(ctx Context, name, ip, port, quorum string) *redis.StringCmd func github.com/go-redis/redis/v8.(*SentinelClient).Ping(ctx Context) *redis.StringCmd func github.com/go-redis/redis/v8.(*SentinelClient).Process(ctx Context, cmd redis.Cmder) error func github.com/go-redis/redis/v8.(*SentinelClient).PSubscribe(ctx Context, channels ...string) *redis.PubSub func github.com/go-redis/redis/v8.(*SentinelClient).Remove(ctx Context, name string) *redis.StringCmd func github.com/go-redis/redis/v8.(*SentinelClient).Reset(ctx Context, pattern string) *redis.IntCmd func github.com/go-redis/redis/v8.(*SentinelClient).Sentinels(ctx Context, name string) *redis.SliceCmd func github.com/go-redis/redis/v8.(*SentinelClient).Set(ctx Context, name, option, value string) *redis.StringCmd func github.com/go-redis/redis/v8.(*SentinelClient).Slaves(ctx Context, name string) *redis.SliceCmd func github.com/go-redis/redis/v8.(*SentinelClient).Subscribe(ctx Context, channels ...string) *redis.PubSub func github.com/go-redis/redis/v8.(*SentinelClient).WithContext(ctx Context) *redis.SentinelClient func github.com/go-redis/redis/v8.StatefulCmdable.Append(ctx Context, key, value string) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.Auth(ctx Context, password string) *redis.StatusCmd func github.com/go-redis/redis/v8.StatefulCmdable.AuthACL(ctx Context, username, password string) *redis.StatusCmd func github.com/go-redis/redis/v8.StatefulCmdable.BgRewriteAOF(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.StatefulCmdable.BgSave(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.StatefulCmdable.BitCount(ctx Context, key string, bitCount *redis.BitCount) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.BitField(ctx Context, key string, args ...interface{}) *redis.IntSliceCmd func github.com/go-redis/redis/v8.StatefulCmdable.BitOpAnd(ctx Context, destKey string, keys ...string) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.BitOpNot(ctx Context, destKey string, key string) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.BitOpOr(ctx Context, destKey string, keys ...string) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.BitOpXor(ctx Context, destKey string, keys ...string) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.BitPos(ctx Context, key string, bit int64, pos ...int64) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.BLPop(ctx Context, timeout time.Duration, keys ...string) *redis.StringSliceCmd func github.com/go-redis/redis/v8.StatefulCmdable.BRPop(ctx Context, timeout time.Duration, keys ...string) *redis.StringSliceCmd func github.com/go-redis/redis/v8.StatefulCmdable.BRPopLPush(ctx Context, source, destination string, timeout time.Duration) *redis.StringCmd func github.com/go-redis/redis/v8.StatefulCmdable.BZPopMax(ctx Context, timeout time.Duration, keys ...string) *redis.ZWithKeyCmd func github.com/go-redis/redis/v8.StatefulCmdable.BZPopMin(ctx Context, timeout time.Duration, keys ...string) *redis.ZWithKeyCmd func github.com/go-redis/redis/v8.StatefulCmdable.ClientGetName(ctx Context) *redis.StringCmd func github.com/go-redis/redis/v8.StatefulCmdable.ClientID(ctx Context) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.ClientKill(ctx Context, ipPort string) *redis.StatusCmd func github.com/go-redis/redis/v8.StatefulCmdable.ClientKillByFilter(ctx Context, keys ...string) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.ClientList(ctx Context) *redis.StringCmd func github.com/go-redis/redis/v8.StatefulCmdable.ClientPause(ctx Context, dur time.Duration) *redis.BoolCmd func github.com/go-redis/redis/v8.StatefulCmdable.ClientSetName(ctx Context, name string) *redis.BoolCmd func github.com/go-redis/redis/v8.StatefulCmdable.ClusterAddSlots(ctx Context, slots ...int) *redis.StatusCmd func github.com/go-redis/redis/v8.StatefulCmdable.ClusterAddSlotsRange(ctx Context, min, max int) *redis.StatusCmd func github.com/go-redis/redis/v8.StatefulCmdable.ClusterCountFailureReports(ctx Context, nodeID string) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.ClusterCountKeysInSlot(ctx Context, slot int) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.ClusterDelSlots(ctx Context, slots ...int) *redis.StatusCmd func github.com/go-redis/redis/v8.StatefulCmdable.ClusterDelSlotsRange(ctx Context, min, max int) *redis.StatusCmd func github.com/go-redis/redis/v8.StatefulCmdable.ClusterFailover(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.StatefulCmdable.ClusterForget(ctx Context, nodeID string) *redis.StatusCmd func github.com/go-redis/redis/v8.StatefulCmdable.ClusterGetKeysInSlot(ctx Context, slot int, count int) *redis.StringSliceCmd func github.com/go-redis/redis/v8.StatefulCmdable.ClusterInfo(ctx Context) *redis.StringCmd func github.com/go-redis/redis/v8.StatefulCmdable.ClusterKeySlot(ctx Context, key string) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.ClusterMeet(ctx Context, host, port string) *redis.StatusCmd func github.com/go-redis/redis/v8.StatefulCmdable.ClusterNodes(ctx Context) *redis.StringCmd func github.com/go-redis/redis/v8.StatefulCmdable.ClusterReplicate(ctx Context, nodeID string) *redis.StatusCmd func github.com/go-redis/redis/v8.StatefulCmdable.ClusterResetHard(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.StatefulCmdable.ClusterResetSoft(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.StatefulCmdable.ClusterSaveConfig(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.StatefulCmdable.ClusterSlaves(ctx Context, nodeID string) *redis.StringSliceCmd func github.com/go-redis/redis/v8.StatefulCmdable.ClusterSlots(ctx Context) *redis.ClusterSlotsCmd func github.com/go-redis/redis/v8.StatefulCmdable.Command(ctx Context) *redis.CommandsInfoCmd func github.com/go-redis/redis/v8.StatefulCmdable.ConfigGet(ctx Context, parameter string) *redis.SliceCmd func github.com/go-redis/redis/v8.StatefulCmdable.ConfigResetStat(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.StatefulCmdable.ConfigRewrite(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.StatefulCmdable.ConfigSet(ctx Context, parameter, value string) *redis.StatusCmd func github.com/go-redis/redis/v8.StatefulCmdable.DBSize(ctx Context) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.DebugObject(ctx Context, key string) *redis.StringCmd func github.com/go-redis/redis/v8.StatefulCmdable.Decr(ctx Context, key string) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.DecrBy(ctx Context, key string, decrement int64) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.Del(ctx Context, keys ...string) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.Dump(ctx Context, key string) *redis.StringCmd func github.com/go-redis/redis/v8.StatefulCmdable.Echo(ctx Context, message interface{}) *redis.StringCmd func github.com/go-redis/redis/v8.StatefulCmdable.Eval(ctx Context, script string, keys []string, args ...interface{}) *redis.Cmd func github.com/go-redis/redis/v8.StatefulCmdable.EvalSha(ctx Context, sha1 string, keys []string, args ...interface{}) *redis.Cmd func github.com/go-redis/redis/v8.StatefulCmdable.Exists(ctx Context, keys ...string) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.Expire(ctx Context, key string, expiration time.Duration) *redis.BoolCmd func github.com/go-redis/redis/v8.StatefulCmdable.ExpireAt(ctx Context, key string, tm time.Time) *redis.BoolCmd func github.com/go-redis/redis/v8.StatefulCmdable.FlushAll(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.StatefulCmdable.FlushAllAsync(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.StatefulCmdable.FlushDB(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.StatefulCmdable.FlushDBAsync(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.StatefulCmdable.GeoAdd(ctx Context, key string, geoLocation ...*redis.GeoLocation) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.GeoDist(ctx Context, key string, member1, member2, unit string) *redis.FloatCmd func github.com/go-redis/redis/v8.StatefulCmdable.GeoHash(ctx Context, key string, members ...string) *redis.StringSliceCmd func github.com/go-redis/redis/v8.StatefulCmdable.GeoPos(ctx Context, key string, members ...string) *redis.GeoPosCmd func github.com/go-redis/redis/v8.StatefulCmdable.GeoRadius(ctx Context, key string, longitude, latitude float64, query *redis.GeoRadiusQuery) *redis.GeoLocationCmd func github.com/go-redis/redis/v8.StatefulCmdable.GeoRadiusByMember(ctx Context, key, member string, query *redis.GeoRadiusQuery) *redis.GeoLocationCmd func github.com/go-redis/redis/v8.StatefulCmdable.GeoRadiusByMemberStore(ctx Context, key, member string, query *redis.GeoRadiusQuery) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.GeoRadiusStore(ctx Context, key string, longitude, latitude float64, query *redis.GeoRadiusQuery) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.Get(ctx Context, key string) *redis.StringCmd func github.com/go-redis/redis/v8.StatefulCmdable.GetBit(ctx Context, key string, offset int64) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.GetRange(ctx Context, key string, start, end int64) *redis.StringCmd func github.com/go-redis/redis/v8.StatefulCmdable.GetSet(ctx Context, key string, value interface{}) *redis.StringCmd func github.com/go-redis/redis/v8.StatefulCmdable.HDel(ctx Context, key string, fields ...string) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.HExists(ctx Context, key, field string) *redis.BoolCmd func github.com/go-redis/redis/v8.StatefulCmdable.HGet(ctx Context, key, field string) *redis.StringCmd func github.com/go-redis/redis/v8.StatefulCmdable.HGetAll(ctx Context, key string) *redis.StringStringMapCmd func github.com/go-redis/redis/v8.StatefulCmdable.HIncrBy(ctx Context, key, field string, incr int64) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.HIncrByFloat(ctx Context, key, field string, incr float64) *redis.FloatCmd func github.com/go-redis/redis/v8.StatefulCmdable.HKeys(ctx Context, key string) *redis.StringSliceCmd func github.com/go-redis/redis/v8.StatefulCmdable.HLen(ctx Context, key string) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.HMGet(ctx Context, key string, fields ...string) *redis.SliceCmd func github.com/go-redis/redis/v8.StatefulCmdable.HMSet(ctx Context, key string, values ...interface{}) *redis.BoolCmd func github.com/go-redis/redis/v8.StatefulCmdable.HScan(ctx Context, key string, cursor uint64, match string, count int64) *redis.ScanCmd func github.com/go-redis/redis/v8.StatefulCmdable.HSet(ctx Context, key string, values ...interface{}) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.HSetNX(ctx Context, key, field string, value interface{}) *redis.BoolCmd func github.com/go-redis/redis/v8.StatefulCmdable.HVals(ctx Context, key string) *redis.StringSliceCmd func github.com/go-redis/redis/v8.StatefulCmdable.Incr(ctx Context, key string) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.IncrBy(ctx Context, key string, value int64) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.IncrByFloat(ctx Context, key string, value float64) *redis.FloatCmd func github.com/go-redis/redis/v8.StatefulCmdable.Info(ctx Context, section ...string) *redis.StringCmd func github.com/go-redis/redis/v8.StatefulCmdable.Keys(ctx Context, pattern string) *redis.StringSliceCmd func github.com/go-redis/redis/v8.StatefulCmdable.LastSave(ctx Context) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.LIndex(ctx Context, key string, index int64) *redis.StringCmd func github.com/go-redis/redis/v8.StatefulCmdable.LInsert(ctx Context, key, op string, pivot, value interface{}) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.LInsertAfter(ctx Context, key string, pivot, value interface{}) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.LInsertBefore(ctx Context, key string, pivot, value interface{}) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.LLen(ctx Context, key string) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.LPop(ctx Context, key string) *redis.StringCmd func github.com/go-redis/redis/v8.StatefulCmdable.LPush(ctx Context, key string, values ...interface{}) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.LPushX(ctx Context, key string, values ...interface{}) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.LRange(ctx Context, key string, start, stop int64) *redis.StringSliceCmd func github.com/go-redis/redis/v8.StatefulCmdable.LRem(ctx Context, key string, count int64, value interface{}) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.LSet(ctx Context, key string, index int64, value interface{}) *redis.StatusCmd func github.com/go-redis/redis/v8.StatefulCmdable.LTrim(ctx Context, key string, start, stop int64) *redis.StatusCmd func github.com/go-redis/redis/v8.StatefulCmdable.MemoryUsage(ctx Context, key string, samples ...int) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.MGet(ctx Context, keys ...string) *redis.SliceCmd func github.com/go-redis/redis/v8.StatefulCmdable.Migrate(ctx Context, host, port, key string, db int, timeout time.Duration) *redis.StatusCmd func github.com/go-redis/redis/v8.StatefulCmdable.Move(ctx Context, key string, db int) *redis.BoolCmd func github.com/go-redis/redis/v8.StatefulCmdable.MSet(ctx Context, values ...interface{}) *redis.StatusCmd func github.com/go-redis/redis/v8.StatefulCmdable.MSetNX(ctx Context, values ...interface{}) *redis.BoolCmd func github.com/go-redis/redis/v8.StatefulCmdable.ObjectEncoding(ctx Context, key string) *redis.StringCmd func github.com/go-redis/redis/v8.StatefulCmdable.ObjectIdleTime(ctx Context, key string) *redis.DurationCmd func github.com/go-redis/redis/v8.StatefulCmdable.ObjectRefCount(ctx Context, key string) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.Persist(ctx Context, key string) *redis.BoolCmd func github.com/go-redis/redis/v8.StatefulCmdable.PExpire(ctx Context, key string, expiration time.Duration) *redis.BoolCmd func github.com/go-redis/redis/v8.StatefulCmdable.PExpireAt(ctx Context, key string, tm time.Time) *redis.BoolCmd func github.com/go-redis/redis/v8.StatefulCmdable.PFAdd(ctx Context, key string, els ...interface{}) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.PFCount(ctx Context, keys ...string) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.PFMerge(ctx Context, dest string, keys ...string) *redis.StatusCmd func github.com/go-redis/redis/v8.StatefulCmdable.Ping(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.StatefulCmdable.Pipelined(ctx Context, fn func(redis.Pipeliner) error) ([]redis.Cmder, error) func github.com/go-redis/redis/v8.StatefulCmdable.PTTL(ctx Context, key string) *redis.DurationCmd func github.com/go-redis/redis/v8.StatefulCmdable.Publish(ctx Context, channel string, message interface{}) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.PubSubChannels(ctx Context, pattern string) *redis.StringSliceCmd func github.com/go-redis/redis/v8.StatefulCmdable.PubSubNumPat(ctx Context) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.PubSubNumSub(ctx Context, channels ...string) *redis.StringIntMapCmd func github.com/go-redis/redis/v8.StatefulCmdable.Quit(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.StatefulCmdable.RandomKey(ctx Context) *redis.StringCmd func github.com/go-redis/redis/v8.StatefulCmdable.ReadOnly(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.StatefulCmdable.ReadWrite(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.StatefulCmdable.Rename(ctx Context, key, newkey string) *redis.StatusCmd func github.com/go-redis/redis/v8.StatefulCmdable.RenameNX(ctx Context, key, newkey string) *redis.BoolCmd func github.com/go-redis/redis/v8.StatefulCmdable.Restore(ctx Context, key string, ttl time.Duration, value string) *redis.StatusCmd func github.com/go-redis/redis/v8.StatefulCmdable.RestoreReplace(ctx Context, key string, ttl time.Duration, value string) *redis.StatusCmd func github.com/go-redis/redis/v8.StatefulCmdable.RPop(ctx Context, key string) *redis.StringCmd func github.com/go-redis/redis/v8.StatefulCmdable.RPopLPush(ctx Context, source, destination string) *redis.StringCmd func github.com/go-redis/redis/v8.StatefulCmdable.RPush(ctx Context, key string, values ...interface{}) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.RPushX(ctx Context, key string, values ...interface{}) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.SAdd(ctx Context, key string, members ...interface{}) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.Save(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.StatefulCmdable.Scan(ctx Context, cursor uint64, match string, count int64) *redis.ScanCmd func github.com/go-redis/redis/v8.StatefulCmdable.SCard(ctx Context, key string) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.ScriptExists(ctx Context, hashes ...string) *redis.BoolSliceCmd func github.com/go-redis/redis/v8.StatefulCmdable.ScriptFlush(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.StatefulCmdable.ScriptKill(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.StatefulCmdable.ScriptLoad(ctx Context, script string) *redis.StringCmd func github.com/go-redis/redis/v8.StatefulCmdable.SDiff(ctx Context, keys ...string) *redis.StringSliceCmd func github.com/go-redis/redis/v8.StatefulCmdable.SDiffStore(ctx Context, destination string, keys ...string) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.Select(ctx Context, index int) *redis.StatusCmd func github.com/go-redis/redis/v8.StatefulCmdable.Set(ctx Context, key string, value interface{}, expiration time.Duration) *redis.StatusCmd func github.com/go-redis/redis/v8.StatefulCmdable.SetBit(ctx Context, key string, offset int64, value int) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.SetNX(ctx Context, key string, value interface{}, expiration time.Duration) *redis.BoolCmd func github.com/go-redis/redis/v8.StatefulCmdable.SetRange(ctx Context, key string, offset int64, value string) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.SetXX(ctx Context, key string, value interface{}, expiration time.Duration) *redis.BoolCmd func github.com/go-redis/redis/v8.StatefulCmdable.Shutdown(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.StatefulCmdable.ShutdownNoSave(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.StatefulCmdable.ShutdownSave(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.StatefulCmdable.SInter(ctx Context, keys ...string) *redis.StringSliceCmd func github.com/go-redis/redis/v8.StatefulCmdable.SInterStore(ctx Context, destination string, keys ...string) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.SIsMember(ctx Context, key string, member interface{}) *redis.BoolCmd func github.com/go-redis/redis/v8.StatefulCmdable.SlaveOf(ctx Context, host, port string) *redis.StatusCmd func github.com/go-redis/redis/v8.StatefulCmdable.SMembers(ctx Context, key string) *redis.StringSliceCmd func github.com/go-redis/redis/v8.StatefulCmdable.SMembersMap(ctx Context, key string) *redis.StringStructMapCmd func github.com/go-redis/redis/v8.StatefulCmdable.SMove(ctx Context, source, destination string, member interface{}) *redis.BoolCmd func github.com/go-redis/redis/v8.StatefulCmdable.Sort(ctx Context, key string, sort *redis.Sort) *redis.StringSliceCmd func github.com/go-redis/redis/v8.StatefulCmdable.SortInterfaces(ctx Context, key string, sort *redis.Sort) *redis.SliceCmd func github.com/go-redis/redis/v8.StatefulCmdable.SortStore(ctx Context, key, store string, sort *redis.Sort) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.SPop(ctx Context, key string) *redis.StringCmd func github.com/go-redis/redis/v8.StatefulCmdable.SPopN(ctx Context, key string, count int64) *redis.StringSliceCmd func github.com/go-redis/redis/v8.StatefulCmdable.SRandMember(ctx Context, key string) *redis.StringCmd func github.com/go-redis/redis/v8.StatefulCmdable.SRandMemberN(ctx Context, key string, count int64) *redis.StringSliceCmd func github.com/go-redis/redis/v8.StatefulCmdable.SRem(ctx Context, key string, members ...interface{}) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.SScan(ctx Context, key string, cursor uint64, match string, count int64) *redis.ScanCmd func github.com/go-redis/redis/v8.StatefulCmdable.StrLen(ctx Context, key string) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.SUnion(ctx Context, keys ...string) *redis.StringSliceCmd func github.com/go-redis/redis/v8.StatefulCmdable.SUnionStore(ctx Context, destination string, keys ...string) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.SwapDB(ctx Context, index1, index2 int) *redis.StatusCmd func github.com/go-redis/redis/v8.StatefulCmdable.Time(ctx Context) *redis.TimeCmd func github.com/go-redis/redis/v8.StatefulCmdable.Touch(ctx Context, keys ...string) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.TTL(ctx Context, key string) *redis.DurationCmd func github.com/go-redis/redis/v8.StatefulCmdable.TxPipelined(ctx Context, fn func(redis.Pipeliner) error) ([]redis.Cmder, error) func github.com/go-redis/redis/v8.StatefulCmdable.Type(ctx Context, key string) *redis.StatusCmd func github.com/go-redis/redis/v8.StatefulCmdable.Unlink(ctx Context, keys ...string) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.XAck(ctx Context, stream, group string, ids ...string) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.XAdd(ctx Context, a *redis.XAddArgs) *redis.StringCmd func github.com/go-redis/redis/v8.StatefulCmdable.XClaim(ctx Context, a *redis.XClaimArgs) *redis.XMessageSliceCmd func github.com/go-redis/redis/v8.StatefulCmdable.XClaimJustID(ctx Context, a *redis.XClaimArgs) *redis.StringSliceCmd func github.com/go-redis/redis/v8.StatefulCmdable.XDel(ctx Context, stream string, ids ...string) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.XGroupCreate(ctx Context, stream, group, start string) *redis.StatusCmd func github.com/go-redis/redis/v8.StatefulCmdable.XGroupCreateMkStream(ctx Context, stream, group, start string) *redis.StatusCmd func github.com/go-redis/redis/v8.StatefulCmdable.XGroupDelConsumer(ctx Context, stream, group, consumer string) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.XGroupDestroy(ctx Context, stream, group string) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.XGroupSetID(ctx Context, stream, group, start string) *redis.StatusCmd func github.com/go-redis/redis/v8.StatefulCmdable.XInfoGroups(ctx Context, key string) *redis.XInfoGroupsCmd func github.com/go-redis/redis/v8.StatefulCmdable.XLen(ctx Context, stream string) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.XPending(ctx Context, stream, group string) *redis.XPendingCmd func github.com/go-redis/redis/v8.StatefulCmdable.XPendingExt(ctx Context, a *redis.XPendingExtArgs) *redis.XPendingExtCmd func github.com/go-redis/redis/v8.StatefulCmdable.XRange(ctx Context, stream, start, stop string) *redis.XMessageSliceCmd func github.com/go-redis/redis/v8.StatefulCmdable.XRangeN(ctx Context, stream, start, stop string, count int64) *redis.XMessageSliceCmd func github.com/go-redis/redis/v8.StatefulCmdable.XRead(ctx Context, a *redis.XReadArgs) *redis.XStreamSliceCmd func github.com/go-redis/redis/v8.StatefulCmdable.XReadGroup(ctx Context, a *redis.XReadGroupArgs) *redis.XStreamSliceCmd func github.com/go-redis/redis/v8.StatefulCmdable.XReadStreams(ctx Context, streams ...string) *redis.XStreamSliceCmd func github.com/go-redis/redis/v8.StatefulCmdable.XRevRange(ctx Context, stream string, start, stop string) *redis.XMessageSliceCmd func github.com/go-redis/redis/v8.StatefulCmdable.XRevRangeN(ctx Context, stream string, start, stop string, count int64) *redis.XMessageSliceCmd func github.com/go-redis/redis/v8.StatefulCmdable.XTrim(ctx Context, key string, maxLen int64) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.XTrimApprox(ctx Context, key string, maxLen int64) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.ZAdd(ctx Context, key string, members ...*redis.Z) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.ZAddCh(ctx Context, key string, members ...*redis.Z) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.ZAddNX(ctx Context, key string, members ...*redis.Z) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.ZAddNXCh(ctx Context, key string, members ...*redis.Z) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.ZAddXX(ctx Context, key string, members ...*redis.Z) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.ZAddXXCh(ctx Context, key string, members ...*redis.Z) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.ZCard(ctx Context, key string) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.ZCount(ctx Context, key, min, max string) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.ZIncr(ctx Context, key string, member *redis.Z) *redis.FloatCmd func github.com/go-redis/redis/v8.StatefulCmdable.ZIncrBy(ctx Context, key string, increment float64, member string) *redis.FloatCmd func github.com/go-redis/redis/v8.StatefulCmdable.ZIncrNX(ctx Context, key string, member *redis.Z) *redis.FloatCmd func github.com/go-redis/redis/v8.StatefulCmdable.ZIncrXX(ctx Context, key string, member *redis.Z) *redis.FloatCmd func github.com/go-redis/redis/v8.StatefulCmdable.ZInterStore(ctx Context, destination string, store *redis.ZStore) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.ZLexCount(ctx Context, key, min, max string) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.ZPopMax(ctx Context, key string, count ...int64) *redis.ZSliceCmd func github.com/go-redis/redis/v8.StatefulCmdable.ZPopMin(ctx Context, key string, count ...int64) *redis.ZSliceCmd func github.com/go-redis/redis/v8.StatefulCmdable.ZRange(ctx Context, key string, start, stop int64) *redis.StringSliceCmd func github.com/go-redis/redis/v8.StatefulCmdable.ZRangeByLex(ctx Context, key string, opt *redis.ZRangeBy) *redis.StringSliceCmd func github.com/go-redis/redis/v8.StatefulCmdable.ZRangeByScore(ctx Context, key string, opt *redis.ZRangeBy) *redis.StringSliceCmd func github.com/go-redis/redis/v8.StatefulCmdable.ZRangeByScoreWithScores(ctx Context, key string, opt *redis.ZRangeBy) *redis.ZSliceCmd func github.com/go-redis/redis/v8.StatefulCmdable.ZRangeWithScores(ctx Context, key string, start, stop int64) *redis.ZSliceCmd func github.com/go-redis/redis/v8.StatefulCmdable.ZRank(ctx Context, key, member string) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.ZRem(ctx Context, key string, members ...interface{}) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.ZRemRangeByLex(ctx Context, key, min, max string) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.ZRemRangeByRank(ctx Context, key string, start, stop int64) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.ZRemRangeByScore(ctx Context, key, min, max string) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.ZRevRange(ctx Context, key string, start, stop int64) *redis.StringSliceCmd func github.com/go-redis/redis/v8.StatefulCmdable.ZRevRangeByLex(ctx Context, key string, opt *redis.ZRangeBy) *redis.StringSliceCmd func github.com/go-redis/redis/v8.StatefulCmdable.ZRevRangeByScore(ctx Context, key string, opt *redis.ZRangeBy) *redis.StringSliceCmd func github.com/go-redis/redis/v8.StatefulCmdable.ZRevRangeByScoreWithScores(ctx Context, key string, opt *redis.ZRangeBy) *redis.ZSliceCmd func github.com/go-redis/redis/v8.StatefulCmdable.ZRevRangeWithScores(ctx Context, key string, start, stop int64) *redis.ZSliceCmd func github.com/go-redis/redis/v8.StatefulCmdable.ZRevRank(ctx Context, key, member string) *redis.IntCmd func github.com/go-redis/redis/v8.StatefulCmdable.ZScan(ctx Context, key string, cursor uint64, match string, count int64) *redis.ScanCmd func github.com/go-redis/redis/v8.StatefulCmdable.ZScore(ctx Context, key, member string) *redis.FloatCmd func github.com/go-redis/redis/v8.StatefulCmdable.ZUnionStore(ctx Context, dest string, store *redis.ZStore) *redis.IntCmd func github.com/go-redis/redis/v8.(*Tx).Close(ctx Context) error func github.com/go-redis/redis/v8.(*Tx).Pipelined(ctx Context, fn func(redis.Pipeliner) error) ([]redis.Cmder, error) func github.com/go-redis/redis/v8.(*Tx).Process(ctx Context, cmd redis.Cmder) error func github.com/go-redis/redis/v8.(*Tx).TxPipelined(ctx Context, fn func(redis.Pipeliner) error) ([]redis.Cmder, error) func github.com/go-redis/redis/v8.(*Tx).Unwatch(ctx Context, keys ...string) *redis.StatusCmd func github.com/go-redis/redis/v8.(*Tx).Watch(ctx Context, keys ...string) *redis.StatusCmd func github.com/go-redis/redis/v8.(*Tx).WithContext(ctx Context) *redis.Tx func github.com/go-redis/redis/v8.UniversalClient.Append(ctx Context, key, value string) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.BgRewriteAOF(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.UniversalClient.BgSave(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.UniversalClient.BitCount(ctx Context, key string, bitCount *redis.BitCount) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.BitField(ctx Context, key string, args ...interface{}) *redis.IntSliceCmd func github.com/go-redis/redis/v8.UniversalClient.BitOpAnd(ctx Context, destKey string, keys ...string) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.BitOpNot(ctx Context, destKey string, key string) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.BitOpOr(ctx Context, destKey string, keys ...string) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.BitOpXor(ctx Context, destKey string, keys ...string) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.BitPos(ctx Context, key string, bit int64, pos ...int64) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.BLPop(ctx Context, timeout time.Duration, keys ...string) *redis.StringSliceCmd func github.com/go-redis/redis/v8.UniversalClient.BRPop(ctx Context, timeout time.Duration, keys ...string) *redis.StringSliceCmd func github.com/go-redis/redis/v8.UniversalClient.BRPopLPush(ctx Context, source, destination string, timeout time.Duration) *redis.StringCmd func github.com/go-redis/redis/v8.UniversalClient.BZPopMax(ctx Context, timeout time.Duration, keys ...string) *redis.ZWithKeyCmd func github.com/go-redis/redis/v8.UniversalClient.BZPopMin(ctx Context, timeout time.Duration, keys ...string) *redis.ZWithKeyCmd func github.com/go-redis/redis/v8.UniversalClient.ClientGetName(ctx Context) *redis.StringCmd func github.com/go-redis/redis/v8.UniversalClient.ClientID(ctx Context) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.ClientKill(ctx Context, ipPort string) *redis.StatusCmd func github.com/go-redis/redis/v8.UniversalClient.ClientKillByFilter(ctx Context, keys ...string) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.ClientList(ctx Context) *redis.StringCmd func github.com/go-redis/redis/v8.UniversalClient.ClientPause(ctx Context, dur time.Duration) *redis.BoolCmd func github.com/go-redis/redis/v8.UniversalClient.ClusterAddSlots(ctx Context, slots ...int) *redis.StatusCmd func github.com/go-redis/redis/v8.UniversalClient.ClusterAddSlotsRange(ctx Context, min, max int) *redis.StatusCmd func github.com/go-redis/redis/v8.UniversalClient.ClusterCountFailureReports(ctx Context, nodeID string) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.ClusterCountKeysInSlot(ctx Context, slot int) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.ClusterDelSlots(ctx Context, slots ...int) *redis.StatusCmd func github.com/go-redis/redis/v8.UniversalClient.ClusterDelSlotsRange(ctx Context, min, max int) *redis.StatusCmd func github.com/go-redis/redis/v8.UniversalClient.ClusterFailover(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.UniversalClient.ClusterForget(ctx Context, nodeID string) *redis.StatusCmd func github.com/go-redis/redis/v8.UniversalClient.ClusterGetKeysInSlot(ctx Context, slot int, count int) *redis.StringSliceCmd func github.com/go-redis/redis/v8.UniversalClient.ClusterInfo(ctx Context) *redis.StringCmd func github.com/go-redis/redis/v8.UniversalClient.ClusterKeySlot(ctx Context, key string) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.ClusterMeet(ctx Context, host, port string) *redis.StatusCmd func github.com/go-redis/redis/v8.UniversalClient.ClusterNodes(ctx Context) *redis.StringCmd func github.com/go-redis/redis/v8.UniversalClient.ClusterReplicate(ctx Context, nodeID string) *redis.StatusCmd func github.com/go-redis/redis/v8.UniversalClient.ClusterResetHard(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.UniversalClient.ClusterResetSoft(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.UniversalClient.ClusterSaveConfig(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.UniversalClient.ClusterSlaves(ctx Context, nodeID string) *redis.StringSliceCmd func github.com/go-redis/redis/v8.UniversalClient.ClusterSlots(ctx Context) *redis.ClusterSlotsCmd func github.com/go-redis/redis/v8.UniversalClient.Command(ctx Context) *redis.CommandsInfoCmd func github.com/go-redis/redis/v8.UniversalClient.ConfigGet(ctx Context, parameter string) *redis.SliceCmd func github.com/go-redis/redis/v8.UniversalClient.ConfigResetStat(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.UniversalClient.ConfigRewrite(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.UniversalClient.ConfigSet(ctx Context, parameter, value string) *redis.StatusCmd func github.com/go-redis/redis/v8.UniversalClient.DBSize(ctx Context) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.DebugObject(ctx Context, key string) *redis.StringCmd func github.com/go-redis/redis/v8.UniversalClient.Decr(ctx Context, key string) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.DecrBy(ctx Context, key string, decrement int64) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.Del(ctx Context, keys ...string) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.Do(ctx Context, args ...interface{}) *redis.Cmd func github.com/go-redis/redis/v8.UniversalClient.Dump(ctx Context, key string) *redis.StringCmd func github.com/go-redis/redis/v8.UniversalClient.Echo(ctx Context, message interface{}) *redis.StringCmd func github.com/go-redis/redis/v8.UniversalClient.Eval(ctx Context, script string, keys []string, args ...interface{}) *redis.Cmd func github.com/go-redis/redis/v8.UniversalClient.EvalSha(ctx Context, sha1 string, keys []string, args ...interface{}) *redis.Cmd func github.com/go-redis/redis/v8.UniversalClient.Exists(ctx Context, keys ...string) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.Expire(ctx Context, key string, expiration time.Duration) *redis.BoolCmd func github.com/go-redis/redis/v8.UniversalClient.ExpireAt(ctx Context, key string, tm time.Time) *redis.BoolCmd func github.com/go-redis/redis/v8.UniversalClient.FlushAll(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.UniversalClient.FlushAllAsync(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.UniversalClient.FlushDB(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.UniversalClient.FlushDBAsync(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.UniversalClient.GeoAdd(ctx Context, key string, geoLocation ...*redis.GeoLocation) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.GeoDist(ctx Context, key string, member1, member2, unit string) *redis.FloatCmd func github.com/go-redis/redis/v8.UniversalClient.GeoHash(ctx Context, key string, members ...string) *redis.StringSliceCmd func github.com/go-redis/redis/v8.UniversalClient.GeoPos(ctx Context, key string, members ...string) *redis.GeoPosCmd func github.com/go-redis/redis/v8.UniversalClient.GeoRadius(ctx Context, key string, longitude, latitude float64, query *redis.GeoRadiusQuery) *redis.GeoLocationCmd func github.com/go-redis/redis/v8.UniversalClient.GeoRadiusByMember(ctx Context, key, member string, query *redis.GeoRadiusQuery) *redis.GeoLocationCmd func github.com/go-redis/redis/v8.UniversalClient.GeoRadiusByMemberStore(ctx Context, key, member string, query *redis.GeoRadiusQuery) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.GeoRadiusStore(ctx Context, key string, longitude, latitude float64, query *redis.GeoRadiusQuery) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.Get(ctx Context, key string) *redis.StringCmd func github.com/go-redis/redis/v8.UniversalClient.GetBit(ctx Context, key string, offset int64) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.GetRange(ctx Context, key string, start, end int64) *redis.StringCmd func github.com/go-redis/redis/v8.UniversalClient.GetSet(ctx Context, key string, value interface{}) *redis.StringCmd func github.com/go-redis/redis/v8.UniversalClient.HDel(ctx Context, key string, fields ...string) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.HExists(ctx Context, key, field string) *redis.BoolCmd func github.com/go-redis/redis/v8.UniversalClient.HGet(ctx Context, key, field string) *redis.StringCmd func github.com/go-redis/redis/v8.UniversalClient.HGetAll(ctx Context, key string) *redis.StringStringMapCmd func github.com/go-redis/redis/v8.UniversalClient.HIncrBy(ctx Context, key, field string, incr int64) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.HIncrByFloat(ctx Context, key, field string, incr float64) *redis.FloatCmd func github.com/go-redis/redis/v8.UniversalClient.HKeys(ctx Context, key string) *redis.StringSliceCmd func github.com/go-redis/redis/v8.UniversalClient.HLen(ctx Context, key string) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.HMGet(ctx Context, key string, fields ...string) *redis.SliceCmd func github.com/go-redis/redis/v8.UniversalClient.HMSet(ctx Context, key string, values ...interface{}) *redis.BoolCmd func github.com/go-redis/redis/v8.UniversalClient.HScan(ctx Context, key string, cursor uint64, match string, count int64) *redis.ScanCmd func github.com/go-redis/redis/v8.UniversalClient.HSet(ctx Context, key string, values ...interface{}) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.HSetNX(ctx Context, key, field string, value interface{}) *redis.BoolCmd func github.com/go-redis/redis/v8.UniversalClient.HVals(ctx Context, key string) *redis.StringSliceCmd func github.com/go-redis/redis/v8.UniversalClient.Incr(ctx Context, key string) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.IncrBy(ctx Context, key string, value int64) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.IncrByFloat(ctx Context, key string, value float64) *redis.FloatCmd func github.com/go-redis/redis/v8.UniversalClient.Info(ctx Context, section ...string) *redis.StringCmd func github.com/go-redis/redis/v8.UniversalClient.Keys(ctx Context, pattern string) *redis.StringSliceCmd func github.com/go-redis/redis/v8.UniversalClient.LastSave(ctx Context) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.LIndex(ctx Context, key string, index int64) *redis.StringCmd func github.com/go-redis/redis/v8.UniversalClient.LInsert(ctx Context, key, op string, pivot, value interface{}) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.LInsertAfter(ctx Context, key string, pivot, value interface{}) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.LInsertBefore(ctx Context, key string, pivot, value interface{}) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.LLen(ctx Context, key string) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.LPop(ctx Context, key string) *redis.StringCmd func github.com/go-redis/redis/v8.UniversalClient.LPush(ctx Context, key string, values ...interface{}) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.LPushX(ctx Context, key string, values ...interface{}) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.LRange(ctx Context, key string, start, stop int64) *redis.StringSliceCmd func github.com/go-redis/redis/v8.UniversalClient.LRem(ctx Context, key string, count int64, value interface{}) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.LSet(ctx Context, key string, index int64, value interface{}) *redis.StatusCmd func github.com/go-redis/redis/v8.UniversalClient.LTrim(ctx Context, key string, start, stop int64) *redis.StatusCmd func github.com/go-redis/redis/v8.UniversalClient.MemoryUsage(ctx Context, key string, samples ...int) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.MGet(ctx Context, keys ...string) *redis.SliceCmd func github.com/go-redis/redis/v8.UniversalClient.Migrate(ctx Context, host, port, key string, db int, timeout time.Duration) *redis.StatusCmd func github.com/go-redis/redis/v8.UniversalClient.Move(ctx Context, key string, db int) *redis.BoolCmd func github.com/go-redis/redis/v8.UniversalClient.MSet(ctx Context, values ...interface{}) *redis.StatusCmd func github.com/go-redis/redis/v8.UniversalClient.MSetNX(ctx Context, values ...interface{}) *redis.BoolCmd func github.com/go-redis/redis/v8.UniversalClient.ObjectEncoding(ctx Context, key string) *redis.StringCmd func github.com/go-redis/redis/v8.UniversalClient.ObjectIdleTime(ctx Context, key string) *redis.DurationCmd func github.com/go-redis/redis/v8.UniversalClient.ObjectRefCount(ctx Context, key string) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.Persist(ctx Context, key string) *redis.BoolCmd func github.com/go-redis/redis/v8.UniversalClient.PExpire(ctx Context, key string, expiration time.Duration) *redis.BoolCmd func github.com/go-redis/redis/v8.UniversalClient.PExpireAt(ctx Context, key string, tm time.Time) *redis.BoolCmd func github.com/go-redis/redis/v8.UniversalClient.PFAdd(ctx Context, key string, els ...interface{}) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.PFCount(ctx Context, keys ...string) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.PFMerge(ctx Context, dest string, keys ...string) *redis.StatusCmd func github.com/go-redis/redis/v8.UniversalClient.Ping(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.UniversalClient.Pipelined(ctx Context, fn func(redis.Pipeliner) error) ([]redis.Cmder, error) func github.com/go-redis/redis/v8.UniversalClient.Process(ctx Context, cmd redis.Cmder) error func github.com/go-redis/redis/v8.UniversalClient.PSubscribe(ctx Context, channels ...string) *redis.PubSub func github.com/go-redis/redis/v8.UniversalClient.PTTL(ctx Context, key string) *redis.DurationCmd func github.com/go-redis/redis/v8.UniversalClient.Publish(ctx Context, channel string, message interface{}) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.PubSubChannels(ctx Context, pattern string) *redis.StringSliceCmd func github.com/go-redis/redis/v8.UniversalClient.PubSubNumPat(ctx Context) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.PubSubNumSub(ctx Context, channels ...string) *redis.StringIntMapCmd func github.com/go-redis/redis/v8.UniversalClient.Quit(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.UniversalClient.RandomKey(ctx Context) *redis.StringCmd func github.com/go-redis/redis/v8.UniversalClient.ReadOnly(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.UniversalClient.ReadWrite(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.UniversalClient.Rename(ctx Context, key, newkey string) *redis.StatusCmd func github.com/go-redis/redis/v8.UniversalClient.RenameNX(ctx Context, key, newkey string) *redis.BoolCmd func github.com/go-redis/redis/v8.UniversalClient.Restore(ctx Context, key string, ttl time.Duration, value string) *redis.StatusCmd func github.com/go-redis/redis/v8.UniversalClient.RestoreReplace(ctx Context, key string, ttl time.Duration, value string) *redis.StatusCmd func github.com/go-redis/redis/v8.UniversalClient.RPop(ctx Context, key string) *redis.StringCmd func github.com/go-redis/redis/v8.UniversalClient.RPopLPush(ctx Context, source, destination string) *redis.StringCmd func github.com/go-redis/redis/v8.UniversalClient.RPush(ctx Context, key string, values ...interface{}) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.RPushX(ctx Context, key string, values ...interface{}) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.SAdd(ctx Context, key string, members ...interface{}) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.Save(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.UniversalClient.Scan(ctx Context, cursor uint64, match string, count int64) *redis.ScanCmd func github.com/go-redis/redis/v8.UniversalClient.SCard(ctx Context, key string) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.ScriptExists(ctx Context, hashes ...string) *redis.BoolSliceCmd func github.com/go-redis/redis/v8.UniversalClient.ScriptFlush(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.UniversalClient.ScriptKill(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.UniversalClient.ScriptLoad(ctx Context, script string) *redis.StringCmd func github.com/go-redis/redis/v8.UniversalClient.SDiff(ctx Context, keys ...string) *redis.StringSliceCmd func github.com/go-redis/redis/v8.UniversalClient.SDiffStore(ctx Context, destination string, keys ...string) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.Set(ctx Context, key string, value interface{}, expiration time.Duration) *redis.StatusCmd func github.com/go-redis/redis/v8.UniversalClient.SetBit(ctx Context, key string, offset int64, value int) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.SetNX(ctx Context, key string, value interface{}, expiration time.Duration) *redis.BoolCmd func github.com/go-redis/redis/v8.UniversalClient.SetRange(ctx Context, key string, offset int64, value string) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.SetXX(ctx Context, key string, value interface{}, expiration time.Duration) *redis.BoolCmd func github.com/go-redis/redis/v8.UniversalClient.Shutdown(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.UniversalClient.ShutdownNoSave(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.UniversalClient.ShutdownSave(ctx Context) *redis.StatusCmd func github.com/go-redis/redis/v8.UniversalClient.SInter(ctx Context, keys ...string) *redis.StringSliceCmd func github.com/go-redis/redis/v8.UniversalClient.SInterStore(ctx Context, destination string, keys ...string) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.SIsMember(ctx Context, key string, member interface{}) *redis.BoolCmd func github.com/go-redis/redis/v8.UniversalClient.SlaveOf(ctx Context, host, port string) *redis.StatusCmd func github.com/go-redis/redis/v8.UniversalClient.SMembers(ctx Context, key string) *redis.StringSliceCmd func github.com/go-redis/redis/v8.UniversalClient.SMembersMap(ctx Context, key string) *redis.StringStructMapCmd func github.com/go-redis/redis/v8.UniversalClient.SMove(ctx Context, source, destination string, member interface{}) *redis.BoolCmd func github.com/go-redis/redis/v8.UniversalClient.Sort(ctx Context, key string, sort *redis.Sort) *redis.StringSliceCmd func github.com/go-redis/redis/v8.UniversalClient.SortInterfaces(ctx Context, key string, sort *redis.Sort) *redis.SliceCmd func github.com/go-redis/redis/v8.UniversalClient.SortStore(ctx Context, key, store string, sort *redis.Sort) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.SPop(ctx Context, key string) *redis.StringCmd func github.com/go-redis/redis/v8.UniversalClient.SPopN(ctx Context, key string, count int64) *redis.StringSliceCmd func github.com/go-redis/redis/v8.UniversalClient.SRandMember(ctx Context, key string) *redis.StringCmd func github.com/go-redis/redis/v8.UniversalClient.SRandMemberN(ctx Context, key string, count int64) *redis.StringSliceCmd func github.com/go-redis/redis/v8.UniversalClient.SRem(ctx Context, key string, members ...interface{}) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.SScan(ctx Context, key string, cursor uint64, match string, count int64) *redis.ScanCmd func github.com/go-redis/redis/v8.UniversalClient.StrLen(ctx Context, key string) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.Subscribe(ctx Context, channels ...string) *redis.PubSub func github.com/go-redis/redis/v8.UniversalClient.SUnion(ctx Context, keys ...string) *redis.StringSliceCmd func github.com/go-redis/redis/v8.UniversalClient.SUnionStore(ctx Context, destination string, keys ...string) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.Time(ctx Context) *redis.TimeCmd func github.com/go-redis/redis/v8.UniversalClient.Touch(ctx Context, keys ...string) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.TTL(ctx Context, key string) *redis.DurationCmd func github.com/go-redis/redis/v8.UniversalClient.TxPipelined(ctx Context, fn func(redis.Pipeliner) error) ([]redis.Cmder, error) func github.com/go-redis/redis/v8.UniversalClient.Type(ctx Context, key string) *redis.StatusCmd func github.com/go-redis/redis/v8.UniversalClient.Unlink(ctx Context, keys ...string) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.Watch(ctx Context, fn func(*redis.Tx) error, keys ...string) error func github.com/go-redis/redis/v8.UniversalClient.XAck(ctx Context, stream, group string, ids ...string) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.XAdd(ctx Context, a *redis.XAddArgs) *redis.StringCmd func github.com/go-redis/redis/v8.UniversalClient.XClaim(ctx Context, a *redis.XClaimArgs) *redis.XMessageSliceCmd func github.com/go-redis/redis/v8.UniversalClient.XClaimJustID(ctx Context, a *redis.XClaimArgs) *redis.StringSliceCmd func github.com/go-redis/redis/v8.UniversalClient.XDel(ctx Context, stream string, ids ...string) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.XGroupCreate(ctx Context, stream, group, start string) *redis.StatusCmd func github.com/go-redis/redis/v8.UniversalClient.XGroupCreateMkStream(ctx Context, stream, group, start string) *redis.StatusCmd func github.com/go-redis/redis/v8.UniversalClient.XGroupDelConsumer(ctx Context, stream, group, consumer string) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.XGroupDestroy(ctx Context, stream, group string) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.XGroupSetID(ctx Context, stream, group, start string) *redis.StatusCmd func github.com/go-redis/redis/v8.UniversalClient.XInfoGroups(ctx Context, key string) *redis.XInfoGroupsCmd func github.com/go-redis/redis/v8.UniversalClient.XLen(ctx Context, stream string) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.XPending(ctx Context, stream, group string) *redis.XPendingCmd func github.com/go-redis/redis/v8.UniversalClient.XPendingExt(ctx Context, a *redis.XPendingExtArgs) *redis.XPendingExtCmd func github.com/go-redis/redis/v8.UniversalClient.XRange(ctx Context, stream, start, stop string) *redis.XMessageSliceCmd func github.com/go-redis/redis/v8.UniversalClient.XRangeN(ctx Context, stream, start, stop string, count int64) *redis.XMessageSliceCmd func github.com/go-redis/redis/v8.UniversalClient.XRead(ctx Context, a *redis.XReadArgs) *redis.XStreamSliceCmd func github.com/go-redis/redis/v8.UniversalClient.XReadGroup(ctx Context, a *redis.XReadGroupArgs) *redis.XStreamSliceCmd func github.com/go-redis/redis/v8.UniversalClient.XReadStreams(ctx Context, streams ...string) *redis.XStreamSliceCmd func github.com/go-redis/redis/v8.UniversalClient.XRevRange(ctx Context, stream string, start, stop string) *redis.XMessageSliceCmd func github.com/go-redis/redis/v8.UniversalClient.XRevRangeN(ctx Context, stream string, start, stop string, count int64) *redis.XMessageSliceCmd func github.com/go-redis/redis/v8.UniversalClient.XTrim(ctx Context, key string, maxLen int64) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.XTrimApprox(ctx Context, key string, maxLen int64) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.ZAdd(ctx Context, key string, members ...*redis.Z) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.ZAddCh(ctx Context, key string, members ...*redis.Z) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.ZAddNX(ctx Context, key string, members ...*redis.Z) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.ZAddNXCh(ctx Context, key string, members ...*redis.Z) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.ZAddXX(ctx Context, key string, members ...*redis.Z) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.ZAddXXCh(ctx Context, key string, members ...*redis.Z) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.ZCard(ctx Context, key string) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.ZCount(ctx Context, key, min, max string) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.ZIncr(ctx Context, key string, member *redis.Z) *redis.FloatCmd func github.com/go-redis/redis/v8.UniversalClient.ZIncrBy(ctx Context, key string, increment float64, member string) *redis.FloatCmd func github.com/go-redis/redis/v8.UniversalClient.ZIncrNX(ctx Context, key string, member *redis.Z) *redis.FloatCmd func github.com/go-redis/redis/v8.UniversalClient.ZIncrXX(ctx Context, key string, member *redis.Z) *redis.FloatCmd func github.com/go-redis/redis/v8.UniversalClient.ZInterStore(ctx Context, destination string, store *redis.ZStore) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.ZLexCount(ctx Context, key, min, max string) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.ZPopMax(ctx Context, key string, count ...int64) *redis.ZSliceCmd func github.com/go-redis/redis/v8.UniversalClient.ZPopMin(ctx Context, key string, count ...int64) *redis.ZSliceCmd func github.com/go-redis/redis/v8.UniversalClient.ZRange(ctx Context, key string, start, stop int64) *redis.StringSliceCmd func github.com/go-redis/redis/v8.UniversalClient.ZRangeByLex(ctx Context, key string, opt *redis.ZRangeBy) *redis.StringSliceCmd func github.com/go-redis/redis/v8.UniversalClient.ZRangeByScore(ctx Context, key string, opt *redis.ZRangeBy) *redis.StringSliceCmd func github.com/go-redis/redis/v8.UniversalClient.ZRangeByScoreWithScores(ctx Context, key string, opt *redis.ZRangeBy) *redis.ZSliceCmd func github.com/go-redis/redis/v8.UniversalClient.ZRangeWithScores(ctx Context, key string, start, stop int64) *redis.ZSliceCmd func github.com/go-redis/redis/v8.UniversalClient.ZRank(ctx Context, key, member string) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.ZRem(ctx Context, key string, members ...interface{}) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.ZRemRangeByLex(ctx Context, key, min, max string) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.ZRemRangeByRank(ctx Context, key string, start, stop int64) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.ZRemRangeByScore(ctx Context, key, min, max string) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.ZRevRange(ctx Context, key string, start, stop int64) *redis.StringSliceCmd func github.com/go-redis/redis/v8.UniversalClient.ZRevRangeByLex(ctx Context, key string, opt *redis.ZRangeBy) *redis.StringSliceCmd func github.com/go-redis/redis/v8.UniversalClient.ZRevRangeByScore(ctx Context, key string, opt *redis.ZRangeBy) *redis.StringSliceCmd func github.com/go-redis/redis/v8.UniversalClient.ZRevRangeByScoreWithScores(ctx Context, key string, opt *redis.ZRangeBy) *redis.ZSliceCmd func github.com/go-redis/redis/v8.UniversalClient.ZRevRangeWithScores(ctx Context, key string, start, stop int64) *redis.ZSliceCmd func github.com/go-redis/redis/v8.UniversalClient.ZRevRank(ctx Context, key, member string) *redis.IntCmd func github.com/go-redis/redis/v8.UniversalClient.ZScan(ctx Context, key string, cursor uint64, match string, count int64) *redis.ScanCmd func github.com/go-redis/redis/v8.UniversalClient.ZScore(ctx Context, key, member string) *redis.FloatCmd func github.com/go-redis/redis/v8.UniversalClient.ZUnionStore(ctx Context, dest string, store *redis.ZStore) *redis.IntCmd func github.com/go-redis/redis/v8/internal.RecordError(ctx Context, err error) error func github.com/go-redis/redis/v8/internal.Sleep(ctx Context, dur time.Duration) error func github.com/go-redis/redis/v8/internal.WithSpan(ctx Context, name string, fn func(Context) error) error func github.com/go-redis/redis/v8/internal.Logging.Printf(ctx Context, format string, v ...interface{}) func github.com/go-redis/redis/v8/internal/pool.(*Conn).WithReader(ctx Context, timeout time.Duration, fn func(rd *proto.Reader) error) error func github.com/go-redis/redis/v8/internal/pool.(*Conn).WithWriter(ctx Context, timeout time.Duration, fn func(wr *proto.Writer) error) error func github.com/go-redis/redis/v8/internal/pool.(*ConnPool).Get(ctx Context) (*pool.Conn, error) func github.com/go-redis/redis/v8/internal/pool.(*ConnPool).NewConn(ctx Context) (*pool.Conn, error) func github.com/go-redis/redis/v8/internal/pool.(*ConnPool).Put(ctx Context, cn *pool.Conn) func github.com/go-redis/redis/v8/internal/pool.(*ConnPool).Remove(ctx Context, cn *pool.Conn, reason error) func github.com/go-redis/redis/v8/internal/pool.Pooler.Get(Context) (*pool.Conn, error) func github.com/go-redis/redis/v8/internal/pool.Pooler.NewConn(Context) (*pool.Conn, error) func github.com/go-redis/redis/v8/internal/pool.Pooler.Put(Context, *pool.Conn) func github.com/go-redis/redis/v8/internal/pool.Pooler.Remove(Context, *pool.Conn, error) func github.com/go-redis/redis/v8/internal/pool.(*SingleConnPool).Get(ctx Context) (*pool.Conn, error) func github.com/go-redis/redis/v8/internal/pool.(*SingleConnPool).NewConn(ctx Context) (*pool.Conn, error) func github.com/go-redis/redis/v8/internal/pool.(*SingleConnPool).Put(ctx Context, cn *pool.Conn) func github.com/go-redis/redis/v8/internal/pool.(*SingleConnPool).Remove(ctx Context, cn *pool.Conn, reason error) func github.com/go-redis/redis/v8/internal/pool.(*StickyConnPool).Get(ctx Context) (*pool.Conn, error) func github.com/go-redis/redis/v8/internal/pool.(*StickyConnPool).NewConn(ctx Context) (*pool.Conn, error) func github.com/go-redis/redis/v8/internal/pool.(*StickyConnPool).Put(ctx Context, cn *pool.Conn) func github.com/go-redis/redis/v8/internal/pool.(*StickyConnPool).Remove(ctx Context, cn *pool.Conn, reason error) func github.com/go-redis/redis/v8/internal/pool.(*StickyConnPool).Reset(ctx Context) error func github.com/go-redis/redis_rate/v9.Limiter.Allow(ctx Context, key string, limit redis_rate.Limit) (*redis_rate.Result, error) func github.com/go-redis/redis_rate/v9.Limiter.AllowAtMost(ctx Context, key string, limit redis_rate.Limit, n int) (*redis_rate.Result, error) func github.com/go-redis/redis_rate/v9.Limiter.AllowN(ctx Context, key string, limit redis_rate.Limit, n int) (*redis_rate.Result, error) func github.com/googleapis/gax-go/v2.Invoke(ctx Context, call gax.APICall, opts ...gax.CallOption) error func github.com/googleapis/gax-go/v2.Sleep(ctx Context, d time.Duration) error func github.com/jackc/pgconn.Connect(ctx Context, connString string) (*pgconn.PgConn, error) func github.com/jackc/pgconn.ConnectConfig(ctx Context, config *pgconn.Config) (pgConn *pgconn.PgConn, err error) func github.com/jackc/pgconn.ValidateConnectTargetSessionAttrsReadWrite(ctx Context, pgConn *pgconn.PgConn) error func github.com/jackc/pgconn.(*PgConn).CancelRequest(ctx Context) error func github.com/jackc/pgconn.(*PgConn).Close(ctx Context) error func github.com/jackc/pgconn.(*PgConn).CopyFrom(ctx Context, r io.Reader, sql string) (pgconn.CommandTag, error) func github.com/jackc/pgconn.(*PgConn).CopyTo(ctx Context, w io.Writer, sql string) (pgconn.CommandTag, error) func github.com/jackc/pgconn.(*PgConn).Exec(ctx Context, sql string) *pgconn.MultiResultReader func github.com/jackc/pgconn.(*PgConn).ExecBatch(ctx Context, batch *pgconn.Batch) *pgconn.MultiResultReader func github.com/jackc/pgconn.(*PgConn).ExecParams(ctx Context, sql string, paramValues [][]byte, paramOIDs []uint32, paramFormats []int16, resultFormats []int16) *pgconn.ResultReader func github.com/jackc/pgconn.(*PgConn).ExecPrepared(ctx Context, stmtName string, paramValues [][]byte, paramFormats []int16, resultFormats []int16) *pgconn.ResultReader func github.com/jackc/pgconn.(*PgConn).Prepare(ctx Context, name, sql string, paramOIDs []uint32) (*pgconn.StatementDescription, error) func github.com/jackc/pgconn.(*PgConn).ReceiveMessage(ctx Context) (pgproto3.BackendMessage, error) func github.com/jackc/pgconn.(*PgConn).ReceiveResults(ctx Context) *pgconn.MultiResultReader func github.com/jackc/pgconn.(*PgConn).SendBytes(ctx Context, buf []byte) error func github.com/jackc/pgconn.(*PgConn).WaitForNotification(ctx Context) error func github.com/jackc/pgconn/internal/ctxwatch.(*ContextWatcher).Watch(ctx Context) func github.com/jackc/pgconn/stmtcache.Cache.Clear(ctx Context) error func github.com/jackc/pgconn/stmtcache.Cache.Get(ctx Context, sql string) (*pgconn.StatementDescription, error) func github.com/jackc/pgconn/stmtcache.(*LRU).Clear(ctx Context) error func github.com/jackc/pgconn/stmtcache.(*LRU).Get(ctx Context, sql string) (*pgconn.StatementDescription, error) func github.com/jackc/pgx/v4.Connect(ctx Context, connString string) (*pgx.Conn, error) func github.com/jackc/pgx/v4.ConnectConfig(ctx Context, connConfig *pgx.ConnConfig) (*pgx.Conn, error) func github.com/jackc/pgx/v4.(*Conn).Begin(ctx Context) (pgx.Tx, error) func github.com/jackc/pgx/v4.(*Conn).BeginFunc(ctx Context, f func(pgx.Tx) error) (err error) func github.com/jackc/pgx/v4.(*Conn).BeginTx(ctx Context, txOptions pgx.TxOptions) (pgx.Tx, error) func github.com/jackc/pgx/v4.(*Conn).BeginTxFunc(ctx Context, txOptions pgx.TxOptions, f func(pgx.Tx) error) (err error) func github.com/jackc/pgx/v4.(*Conn).Close(ctx Context) error func github.com/jackc/pgx/v4.(*Conn).CopyFrom(ctx Context, tableName pgx.Identifier, columnNames []string, rowSrc pgx.CopyFromSource) (int64, error) func github.com/jackc/pgx/v4.(*Conn).Deallocate(ctx Context, name string) error func github.com/jackc/pgx/v4.(*Conn).Exec(ctx Context, sql string, arguments ...interface{}) (pgconn.CommandTag, error) func github.com/jackc/pgx/v4.(*Conn).Ping(ctx Context) error func github.com/jackc/pgx/v4.(*Conn).Prepare(ctx Context, name, sql string) (sd *pgconn.StatementDescription, err error) func github.com/jackc/pgx/v4.(*Conn).Query(ctx Context, sql string, args ...interface{}) (pgx.Rows, error) func github.com/jackc/pgx/v4.(*Conn).QueryFunc(ctx Context, sql string, args []interface{}, scans []interface{}, f func(pgx.QueryFuncRow) error) (pgconn.CommandTag, error) func github.com/jackc/pgx/v4.(*Conn).QueryRow(ctx Context, sql string, args ...interface{}) pgx.Row func github.com/jackc/pgx/v4.(*Conn).SendBatch(ctx Context, b *pgx.Batch) pgx.BatchResults func github.com/jackc/pgx/v4.(*Conn).WaitForNotification(ctx Context) (*pgconn.Notification, error) func github.com/jackc/pgx/v4.(*LargeObjects).Create(ctx Context, oid uint32) (uint32, error) func github.com/jackc/pgx/v4.(*LargeObjects).Open(ctx Context, oid uint32, mode pgx.LargeObjectMode) (*pgx.LargeObject, error) func github.com/jackc/pgx/v4.(*LargeObjects).Unlink(ctx Context, oid uint32) error func github.com/jackc/pgx/v4.Logger.Log(ctx Context, level pgx.LogLevel, msg string, data map[string]interface{}) func github.com/jackc/pgx/v4.Tx.Begin(ctx Context) (pgx.Tx, error) func github.com/jackc/pgx/v4.Tx.BeginFunc(ctx Context, f func(pgx.Tx) error) (err error) func github.com/jackc/pgx/v4.Tx.Commit(ctx Context) error func github.com/jackc/pgx/v4.Tx.CopyFrom(ctx Context, tableName pgx.Identifier, columnNames []string, rowSrc pgx.CopyFromSource) (int64, error) func github.com/jackc/pgx/v4.Tx.Exec(ctx Context, sql string, arguments ...interface{}) (commandTag pgconn.CommandTag, err error) func github.com/jackc/pgx/v4.Tx.Prepare(ctx Context, name, sql string) (*pgconn.StatementDescription, error) func github.com/jackc/pgx/v4.Tx.Query(ctx Context, sql string, args ...interface{}) (pgx.Rows, error) func github.com/jackc/pgx/v4.Tx.QueryFunc(ctx Context, sql string, args []interface{}, scans []interface{}, f func(pgx.QueryFuncRow) error) (pgconn.CommandTag, error) func github.com/jackc/pgx/v4.Tx.QueryRow(ctx Context, sql string, args ...interface{}) pgx.Row func github.com/jackc/pgx/v4.Tx.Rollback(ctx Context) error func github.com/jackc/pgx/v4.Tx.SendBatch(ctx Context, b *pgx.Batch) pgx.BatchResults func github.com/jackc/pgx/v4/stdlib.(*Conn).BeginTx(ctx Context, opts driver.TxOptions) (driver.Tx, error) func github.com/jackc/pgx/v4/stdlib.(*Conn).ExecContext(ctx Context, query string, argsV []driver.NamedValue) (driver.Result, error) func github.com/jackc/pgx/v4/stdlib.(*Conn).Ping(ctx Context) error func github.com/jackc/pgx/v4/stdlib.(*Conn).PrepareContext(ctx Context, query string) (driver.Stmt, error) func github.com/jackc/pgx/v4/stdlib.(*Conn).QueryContext(ctx Context, query string, argsV []driver.NamedValue) (driver.Rows, error) func github.com/jackc/pgx/v4/stdlib.(*Conn).ResetSession(ctx Context) error func github.com/jackc/pgx/v4/stdlib.(*Stmt).ExecContext(ctx Context, argsV []driver.NamedValue) (driver.Result, error) func github.com/jackc/pgx/v4/stdlib.(*Stmt).QueryContext(ctx Context, argsV []driver.NamedValue) (driver.Rows, error) func github.com/jbenet/go-context/io.NewReader(ctx context.Context, r io.Reader) *ctxio.ctxReader func github.com/jbenet/go-context/io.NewWriter(ctx context.Context, w io.Writer) *ctxio.ctxWriter func github.com/lib/pq.(*Connector).Connect(ctx Context) (driver.Conn, error) func github.com/lib/pq.DialerContext.DialContext(ctx Context, network, address string) (net.Conn, error) func github.com/Masterminds/squirrel.ExecContextWith(ctx Context, db squirrel.ExecerContext, s squirrel.Sqlizer) (res sql.Result, err error) func github.com/Masterminds/squirrel.QueryContextWith(ctx Context, db squirrel.QueryerContext, s squirrel.Sqlizer) (rows *sql.Rows, err error) func github.com/Masterminds/squirrel.QueryRowContextWith(ctx Context, db squirrel.QueryRowerContext, s squirrel.Sqlizer) squirrel.RowScanner func github.com/Masterminds/squirrel.DBProxyContext.PrepareContext(ctx Context, query string) (*sql.Stmt, error) func github.com/Masterminds/squirrel.DeleteBuilder.ExecContext(ctx Context) (sql.Result, error) func github.com/Masterminds/squirrel.DeleteBuilder.QueryContext(ctx Context) (*sql.Rows, error) func github.com/Masterminds/squirrel.DeleteBuilder.QueryRowContext(ctx Context) squirrel.RowScanner func github.com/Masterminds/squirrel.DeleteBuilder.ScanContext(ctx Context, dest ...interface{}) error func github.com/Masterminds/squirrel.ExecerContext.ExecContext(ctx Context, query string, args ...interface{}) (sql.Result, error) func github.com/Masterminds/squirrel.InsertBuilder.ExecContext(ctx Context) (sql.Result, error) func github.com/Masterminds/squirrel.InsertBuilder.QueryContext(ctx Context) (*sql.Rows, error) func github.com/Masterminds/squirrel.InsertBuilder.QueryRowContext(ctx Context) squirrel.RowScanner func github.com/Masterminds/squirrel.InsertBuilder.ScanContext(ctx Context, dest ...interface{}) error func github.com/Masterminds/squirrel.PreparerContext.PrepareContext(ctx Context, query string) (*sql.Stmt, error) func github.com/Masterminds/squirrel.QueryerContext.QueryContext(ctx Context, query string, args ...interface{}) (*sql.Rows, error) func github.com/Masterminds/squirrel.QueryRowerContext.QueryRowContext(ctx Context, query string, args ...interface{}) squirrel.RowScanner func github.com/Masterminds/squirrel.RunnerContext.ExecContext(ctx Context, query string, args ...interface{}) (sql.Result, error) func github.com/Masterminds/squirrel.RunnerContext.QueryContext(ctx Context, query string, args ...interface{}) (*sql.Rows, error) func github.com/Masterminds/squirrel.RunnerContext.QueryRowContext(ctx Context, query string, args ...interface{}) squirrel.RowScanner func github.com/Masterminds/squirrel.SelectBuilder.ExecContext(ctx Context) (sql.Result, error) func github.com/Masterminds/squirrel.SelectBuilder.QueryContext(ctx Context) (*sql.Rows, error) func github.com/Masterminds/squirrel.SelectBuilder.QueryRowContext(ctx Context) squirrel.RowScanner func github.com/Masterminds/squirrel.SelectBuilder.ScanContext(ctx Context, dest ...interface{}) error func github.com/Masterminds/squirrel.StdSqlCtx.ExecContext(Context, string, ...interface{}) (sql.Result, error) func github.com/Masterminds/squirrel.StdSqlCtx.QueryContext(Context, string, ...interface{}) (*sql.Rows, error) func github.com/Masterminds/squirrel.StdSqlCtx.QueryRowContext(Context, string, ...interface{}) *sql.Row func github.com/Masterminds/squirrel.(*StmtCache).ExecContext(ctx Context, query string, args ...interface{}) (res sql.Result, err error) func github.com/Masterminds/squirrel.(*StmtCache).PrepareContext(ctx Context, query string) (*sql.Stmt, error) func github.com/Masterminds/squirrel.(*StmtCache).QueryContext(ctx Context, query string, args ...interface{}) (rows *sql.Rows, err error) func github.com/Masterminds/squirrel.(*StmtCache).QueryRowContext(ctx Context, query string, args ...interface{}) squirrel.RowScanner func github.com/Masterminds/squirrel.UpdateBuilder.ExecContext(ctx Context) (sql.Result, error) func github.com/Masterminds/squirrel.UpdateBuilder.QueryContext(ctx Context) (*sql.Rows, error) func github.com/Masterminds/squirrel.UpdateBuilder.QueryRowContext(ctx Context) squirrel.RowScanner func github.com/Masterminds/squirrel.UpdateBuilder.ScanContext(ctx Context, dest ...interface{}) error func go.opencensus.io/metric/metricexport.Exporter.ExportMetrics(ctx Context, data []*metricdata.Metric) error func go.opencensus.io/plugin/ocgrpc.(*ClientHandler).HandleConn(ctx Context, cs stats.ConnStats) func go.opencensus.io/plugin/ocgrpc.(*ClientHandler).HandleRPC(ctx Context, rs stats.RPCStats) func go.opencensus.io/plugin/ocgrpc.(*ClientHandler).TagConn(ctx Context, cti *stats.ConnTagInfo) Context func go.opencensus.io/plugin/ocgrpc.(*ClientHandler).TagRPC(ctx Context, rti *stats.RPCTagInfo) Context func go.opencensus.io/plugin/ocgrpc.(*ServerHandler).HandleConn(ctx Context, cs stats.ConnStats) func go.opencensus.io/plugin/ocgrpc.(*ServerHandler).HandleRPC(ctx Context, rs stats.RPCStats) func go.opencensus.io/plugin/ocgrpc.(*ServerHandler).TagConn(ctx Context, cti *stats.ConnTagInfo) Context func go.opencensus.io/plugin/ocgrpc.(*ServerHandler).TagRPC(ctx Context, rti *stats.RPCTagInfo) Context func go.opencensus.io/plugin/ochttp.SetRoute(ctx Context, route string) func go.opencensus.io/resource.FromEnv(Context) (*resource.Resource, error) func go.opencensus.io/stats.Record(ctx Context, ms ...stats.Measurement) func go.opencensus.io/stats.RecordWithOptions(ctx Context, ros ...stats.Options) error func go.opencensus.io/stats.RecordWithTags(ctx Context, mutators []tag.Mutator, ms ...stats.Measurement) error func go.opencensus.io/tag.Do(ctx Context, f func(ctx Context)) func go.opencensus.io/tag.FromContext(ctx Context) *tag.Map func go.opencensus.io/tag.New(ctx Context, mutator ...tag.Mutator) (Context, error) func go.opencensus.io/tag.NewContext(ctx Context, m *tag.Map) Context func go.opencensus.io/trace.FromContext(ctx Context) *trace.Span func go.opencensus.io/trace.NewContext(parent Context, s *trace.Span) Context func go.opencensus.io/trace.StartSpan(ctx Context, name string, o ...trace.StartOption) (Context, *trace.Span) func go.opencensus.io/trace.StartSpanWithRemoteParent(ctx Context, name string, parent trace.SpanContext, o ...trace.StartOption) (Context, *trace.Span) func go.opentelemetry.io/otel.Tracer.Start(ctx Context, spanName string, opts ...trace.StartOption) (Context, trace.Span) func go.opentelemetry.io/otel/api/correlation.ContextWithGetHook(ctx Context, hook correlation.GetHookFunc) Context func go.opentelemetry.io/otel/api/correlation.ContextWithMap(ctx Context, m correlation.Map) Context func go.opentelemetry.io/otel/api/correlation.ContextWithNoHooks(ctx Context) (Context, correlation.SetHookFunc, correlation.GetHookFunc) func go.opentelemetry.io/otel/api/correlation.ContextWithSetHook(ctx Context, hook correlation.SetHookFunc) Context func go.opentelemetry.io/otel/api/correlation.MapFromContext(ctx Context) correlation.Map func go.opentelemetry.io/otel/api/correlation.NewContext(ctx Context, keyvalues ...label.KeyValue) Context func go.opentelemetry.io/otel/api/correlation.CorrelationContext.Extract(ctx Context, supplier propagation.HTTPSupplier) Context func go.opentelemetry.io/otel/api/correlation.CorrelationContext.Inject(ctx Context, supplier propagation.HTTPSupplier) func go.opentelemetry.io/otel/api/metric.AsyncBatchRunner.Run(ctx Context, capture func([]label.KeyValue, ...metric.Observation)) func go.opentelemetry.io/otel/api/metric.AsyncSingleRunner.Run(ctx Context, single metric.AsyncImpl, capture func([]label.KeyValue, ...metric.Observation)) func go.opentelemetry.io/otel/api/metric.(*BatchObserverFunc).Run(ctx Context, function func([]label.KeyValue, ...metric.Observation)) func go.opentelemetry.io/otel/api/metric.BoundFloat64Counter.Add(ctx Context, value float64) func go.opentelemetry.io/otel/api/metric.BoundFloat64UpDownCounter.Add(ctx Context, value float64) func go.opentelemetry.io/otel/api/metric.BoundFloat64ValueRecorder.Record(ctx Context, value float64) func go.opentelemetry.io/otel/api/metric.BoundInt64Counter.Add(ctx Context, value int64) func go.opentelemetry.io/otel/api/metric.BoundInt64UpDownCounter.Add(ctx Context, value int64) func go.opentelemetry.io/otel/api/metric.BoundInt64ValueRecorder.Record(ctx Context, value int64) func go.opentelemetry.io/otel/api/metric.BoundSyncImpl.RecordOne(ctx Context, number metric.Number) func go.opentelemetry.io/otel/api/metric.Float64Counter.Add(ctx Context, value float64, labels ...label.KeyValue) func go.opentelemetry.io/otel/api/metric.(*Float64ObserverFunc).Run(ctx Context, impl metric.AsyncImpl, function func([]label.KeyValue, ...metric.Observation)) func go.opentelemetry.io/otel/api/metric.Float64UpDownCounter.Add(ctx Context, value float64, labels ...label.KeyValue) func go.opentelemetry.io/otel/api/metric.Float64ValueRecorder.Record(ctx Context, value float64, labels ...label.KeyValue) func go.opentelemetry.io/otel/api/metric.Int64Counter.Add(ctx Context, value int64, labels ...label.KeyValue) func go.opentelemetry.io/otel/api/metric.(*Int64ObserverFunc).Run(ctx Context, impl metric.AsyncImpl, function func([]label.KeyValue, ...metric.Observation)) func go.opentelemetry.io/otel/api/metric.Int64UpDownCounter.Add(ctx Context, value int64, labels ...label.KeyValue) func go.opentelemetry.io/otel/api/metric.Int64ValueRecorder.Record(ctx Context, value int64, labels ...label.KeyValue) func go.opentelemetry.io/otel/api/metric.Meter.RecordBatch(ctx Context, ls []label.KeyValue, ms ...metric.Measurement) func go.opentelemetry.io/otel/api/metric.MeterImpl.RecordBatch(Context, []label.KeyValue, ...metric.Measurement) func go.opentelemetry.io/otel/api/metric.NoopSync.RecordOne(Context, metric.Number, []label.KeyValue) func go.opentelemetry.io/otel/api/metric.SyncImpl.RecordOne(ctx Context, number metric.Number, labels []label.KeyValue) func go.opentelemetry.io/otel/api/propagation.ExtractHTTP(ctx Context, props propagation.Propagators, supplier propagation.HTTPSupplier) Context func go.opentelemetry.io/otel/api/propagation.InjectHTTP(ctx Context, props propagation.Propagators, supplier propagation.HTTPSupplier) func go.opentelemetry.io/otel/api/propagation.HTTPExtractor.Extract(Context, propagation.HTTPSupplier) Context func go.opentelemetry.io/otel/api/propagation.HTTPInjector.Inject(Context, propagation.HTTPSupplier) func go.opentelemetry.io/otel/api/propagation.HTTPPropagator.Extract(Context, propagation.HTTPSupplier) Context func go.opentelemetry.io/otel/api/propagation.HTTPPropagator.Inject(Context, propagation.HTTPSupplier) func go.opentelemetry.io/otel/api/trace.ContextWithRemoteSpanContext(ctx Context, sc trace.SpanContext) Context func go.opentelemetry.io/otel/api/trace.ContextWithSpan(ctx Context, span trace.Span) Context func go.opentelemetry.io/otel/api/trace.RemoteSpanContextFromContext(ctx Context) trace.SpanContext func go.opentelemetry.io/otel/api/trace.SpanFromContext(ctx Context) trace.Span func go.opentelemetry.io/otel/api/trace.B3.Extract(ctx Context, supplier propagation.HTTPSupplier) Context func go.opentelemetry.io/otel/api/trace.B3.Inject(ctx Context, supplier propagation.HTTPSupplier) func go.opentelemetry.io/otel/api/trace.NoopSpan.AddEvent(ctx Context, name string, attrs ...label.KeyValue) func go.opentelemetry.io/otel/api/trace.NoopSpan.AddEventWithTimestamp(ctx Context, timestamp time.Time, name string, attrs ...label.KeyValue) func go.opentelemetry.io/otel/api/trace.NoopSpan.RecordError(ctx Context, err error, opts ...trace.ErrorOption) func go.opentelemetry.io/otel/api/trace.NoopTracer.Start(ctx Context, name string, opts ...trace.StartOption) (Context, trace.Span) func go.opentelemetry.io/otel/api/trace.Span.AddEvent(ctx Context, name string, attrs ...label.KeyValue) func go.opentelemetry.io/otel/api/trace.Span.AddEventWithTimestamp(ctx Context, timestamp time.Time, name string, attrs ...label.KeyValue) func go.opentelemetry.io/otel/api/trace.Span.RecordError(ctx Context, err error, opts ...trace.ErrorOption) func go.opentelemetry.io/otel/api/trace.TraceContext.Extract(ctx Context, supplier propagation.HTTPSupplier) Context func go.opentelemetry.io/otel/api/trace.TraceContext.Inject(ctx Context, supplier propagation.HTTPSupplier) func go.opentelemetry.io/otel/api/trace.Tracer.Start(ctx Context, spanName string, opts ...trace.StartOption) (Context, trace.Span) func golang.org/x/net/context.WithCancel(parent context.Context) (ctx context.Context, cancel context.CancelFunc) func golang.org/x/net/context.WithDeadline(parent context.Context, deadline time.Time) (context.Context, context.CancelFunc) func golang.org/x/net/context.WithTimeout(parent context.Context, timeout time.Duration) (context.Context, context.CancelFunc) func golang.org/x/net/context.WithValue(parent context.Context, key interface{}, val interface{}) context.Context func golang.org/x/net/context/ctxhttp.Do(ctx Context, client *http.Client, req *http.Request) (*http.Response, error) func golang.org/x/net/context/ctxhttp.Get(ctx Context, client *http.Client, url string) (*http.Response, error) func golang.org/x/net/context/ctxhttp.Head(ctx Context, client *http.Client, url string) (*http.Response, error) func golang.org/x/net/context/ctxhttp.Post(ctx Context, client *http.Client, url string, bodyType string, body io.Reader) (*http.Response, error) func golang.org/x/net/context/ctxhttp.PostForm(ctx Context, client *http.Client, url string, data url.Values) (*http.Response, error) func golang.org/x/net/http2.(*ClientConn).Ping(ctx Context) error func golang.org/x/net/http2.(*ClientConn).Shutdown(ctx Context) error func golang.org/x/net/internal/socks.(*Dialer).DialContext(ctx Context, network, address string) (net.Conn, error) func golang.org/x/net/internal/socks.(*Dialer).DialWithConn(ctx Context, c net.Conn, network, address string) (net.Addr, error) func golang.org/x/net/internal/socks.(*UsernamePassword).Authenticate(ctx Context, rw io.ReadWriter, auth socks.AuthMethod) error func golang.org/x/net/proxy.Dial(ctx Context, network, address string) (net.Conn, error) func golang.org/x/net/proxy.ContextDialer.DialContext(ctx Context, network, address string) (net.Conn, error) func golang.org/x/net/proxy.(*PerHost).DialContext(ctx Context, network, addr string) (c net.Conn, err error) func golang.org/x/net/trace.FromContext(ctx Context) (tr trace.Trace, ok bool) func golang.org/x/net/trace.NewContext(ctx Context, tr trace.Trace) Context func golang.org/x/oauth2.NewClient(ctx Context, src oauth2.TokenSource) *http.Client func golang.org/x/oauth2.(*Config).Client(ctx Context, t *oauth2.Token) *http.Client func golang.org/x/oauth2.(*Config).Exchange(ctx Context, code string, opts ...oauth2.AuthCodeOption) (*oauth2.Token, error) func golang.org/x/oauth2.(*Config).PasswordCredentialsToken(ctx Context, username, password string) (*oauth2.Token, error) func golang.org/x/oauth2.(*Config).TokenSource(ctx Context, t *oauth2.Token) oauth2.TokenSource func golang.org/x/oauth2/google.AppEngineTokenSource(ctx Context, scope ...string) oauth2.TokenSource func golang.org/x/oauth2/google.CredentialsFromJSON(ctx Context, jsonData []byte, scopes ...string) (*google.Credentials, error) func golang.org/x/oauth2/google.DefaultClient(ctx Context, scope ...string) (*http.Client, error) func golang.org/x/oauth2/google.DefaultTokenSource(ctx Context, scope ...string) (oauth2.TokenSource, error) func golang.org/x/oauth2/google.FindDefaultCredentials(ctx Context, scopes ...string) (*google.Credentials, error) func golang.org/x/oauth2/google.(*SDKConfig).Client(ctx Context) *http.Client func golang.org/x/oauth2/google.(*SDKConfig).TokenSource(ctx Context) oauth2.TokenSource func golang.org/x/oauth2/internal.ContextClient(ctx Context) *http.Client func golang.org/x/oauth2/internal.RetrieveToken(ctx Context, clientID, clientSecret, tokenURL string, v url.Values, authStyle internal.AuthStyle) (*internal.Token, error) func golang.org/x/oauth2/jwt.(*Config).Client(ctx Context) *http.Client func golang.org/x/oauth2/jwt.(*Config).TokenSource(ctx Context) oauth2.TokenSource func golang.org/x/pkgsite/cmd/internal/cmdconfig.Experimenter(ctx Context, cfg *config.Config, getter middleware.ExperimentGetter, reportingClient *errorreporting.Client) *middleware.Experimenter func golang.org/x/pkgsite/cmd/internal/cmdconfig.ExperimentGetter(ctx Context, cfg *config.Config) middleware.ExperimentGetter func golang.org/x/pkgsite/cmd/internal/cmdconfig.Logger(ctx Context, cfg *config.Config, logName string) middleware.Logger func golang.org/x/pkgsite/cmd/internal/cmdconfig.OpenDB(ctx Context, cfg *config.Config, bypassLicenseCheck bool) (_ *postgres.DB, err error) func golang.org/x/pkgsite/cmd/internal/cmdconfig.ReportingClient(ctx Context, cfg *config.Config) *errorreporting.Client func golang.org/x/pkgsite/internal.DataSource.GetLatestInfo(ctx Context, unitPath, modulePath string, latestUnitMeta *internal.UnitMeta) (internal.LatestInfo, error) func golang.org/x/pkgsite/internal.DataSource.GetModuleReadme(ctx Context, modulePath, resolvedVersion string) (*internal.Readme, error) func golang.org/x/pkgsite/internal.DataSource.GetNestedModules(ctx Context, modulePath string) ([]*internal.ModuleInfo, error) func golang.org/x/pkgsite/internal.DataSource.GetUnit(ctx Context, pathInfo *internal.UnitMeta, fields internal.FieldSet, bc internal.BuildContext) (_ *internal.Unit, err error) func golang.org/x/pkgsite/internal.DataSource.GetUnitMeta(ctx Context, path, requestedModulePath, requestedVersion string) (_ *internal.UnitMeta, err error) func golang.org/x/pkgsite/internal/auth.Header(ctx Context, jsonCreds []byte, useExp bool) (_ string, err error) func golang.org/x/pkgsite/internal/auth.NewClient(ctx Context, jsonCreds []byte, useExp bool) (_ *http.Client, err error) func golang.org/x/pkgsite/internal/cache.(*Cache).Clear(ctx Context) (err error) func golang.org/x/pkgsite/internal/cache.(*Cache).Delete(ctx Context, keys ...string) (err error) func golang.org/x/pkgsite/internal/cache.(*Cache).DeletePrefix(ctx Context, prefix string) (err error) func golang.org/x/pkgsite/internal/cache.(*Cache).Get(ctx Context, key string) (value []byte, err error) func golang.org/x/pkgsite/internal/cache.(*Cache).Put(ctx Context, key string, data []byte, ttl time.Duration) (err error) func golang.org/x/pkgsite/internal/config.Init(ctx Context) (_ *config.Config, err error) func golang.org/x/pkgsite/internal/config/dynconfig.Read(ctx Context, location string) (_ *dynconfig.DynamicConfig, err error) func golang.org/x/pkgsite/internal/database.(*DB).BulkInsert(ctx Context, table string, columns []string, values []interface{}, conflictAction string) (err error) func golang.org/x/pkgsite/internal/database.(*DB).BulkInsertReturning(ctx Context, table string, columns []string, values []interface{}, conflictAction string, returningColumns []string, scanFunc func(*sql.Rows) error) (err error) func golang.org/x/pkgsite/internal/database.(*DB).BulkUpdate(ctx Context, table string, columns, types []string, values [][]interface{}) (err error) func golang.org/x/pkgsite/internal/database.(*DB).BulkUpsert(ctx Context, table string, columns []string, values []interface{}, conflictColumns []string) error func golang.org/x/pkgsite/internal/database.(*DB).BulkUpsertReturning(ctx Context, table string, columns []string, values []interface{}, conflictColumns, returningColumns []string, scanFunc func(*sql.Rows) error) error func golang.org/x/pkgsite/internal/database.(*DB).CollectStructs(ctx Context, pslice interface{}, query string, args ...interface{}) error func golang.org/x/pkgsite/internal/database.(*DB).CopyUpsert(ctx Context, table string, columns []string, src pgx.CopyFromSource, conflictColumns []string, dropColumn string) (err error) func golang.org/x/pkgsite/internal/database.(*DB).Exec(ctx Context, query string, args ...interface{}) (_ int64, err error) func golang.org/x/pkgsite/internal/database.(*DB).Prepare(ctx Context, query string) (*sql.Stmt, error) func golang.org/x/pkgsite/internal/database.(*DB).Query(ctx Context, query string, args ...interface{}) (_ *sql.Rows, err error) func golang.org/x/pkgsite/internal/database.(*DB).QueryRow(ctx Context, query string, args ...interface{}) *sql.Row func golang.org/x/pkgsite/internal/database.(*DB).RunQuery(ctx Context, query string, f func(*sql.Rows) error, params ...interface{}) error func golang.org/x/pkgsite/internal/database.(*DB).Transact(ctx Context, iso sql.IsolationLevel, txFunc func(*database.DB) error) (err error) func golang.org/x/pkgsite/internal/dcensus.RecordWithTag(ctx Context, key tag.Key, val string, m stats.Measurement) func golang.org/x/pkgsite/internal/experiment.FromContext(ctx Context) *experiment.Set func golang.org/x/pkgsite/internal/experiment.IsActive(ctx Context, experiment string) bool func golang.org/x/pkgsite/internal/experiment.NewContext(ctx Context, experimentNames ...string) Context func golang.org/x/pkgsite/internal/fetch.FetchLocalModule(ctx Context, modulePath, localPath string, sourceClient *source.Client) *fetch.FetchResult func golang.org/x/pkgsite/internal/fetch.FetchModule(ctx Context, modulePath, requestedVersion string, proxyClient *proxy.Client, sourceClient *source.Client) (fr *fetch.FetchResult) func golang.org/x/pkgsite/internal/fetch.GetInfo(ctx Context, modulePath, requestedVersion string, proxyClient *proxy.Client) (_ *proxy.VersionInfo, err error) func golang.org/x/pkgsite/internal/fetch.LatestModuleVersions(ctx Context, modulePath string, prox *proxy.Client, hasGoMod func(v string) (bool, error)) (info *internal.LatestModuleVersions, err error) func golang.org/x/pkgsite/internal/frontend.FetchAndUpdateState(ctx Context, modulePath, requestedVersion string, proxyClient *proxy.Client, sourceClient *source.Client, db *postgres.DB) (_ int, err error) func golang.org/x/pkgsite/internal/frontend.LegacyReadmeHTML(ctx Context, mi *internal.ModuleInfo, readme *internal.Readme) (_ safehtml.HTML, err error) func golang.org/x/pkgsite/internal/frontend.ProcessReadme(ctx Context, u *internal.Unit) (_ *frontend.Readme, err error) func golang.org/x/pkgsite/internal/frontend.(*Server).GetLatestInfo(ctx Context, unitPath, modulePath string, latestUnitMeta *internal.UnitMeta) internal.LatestInfo func golang.org/x/pkgsite/internal/godoc.RenderFromUnit(ctx Context, u *internal.Unit) (_ *dochtml.Parts, err error) func golang.org/x/pkgsite/internal/godoc.(*Package).DocInfo(ctx Context, innerPath string, sourceInfo *source.Info, modInfo *godoc.ModuleInfo) (synopsis string, imports []string, api []*internal.Symbol, err error) func golang.org/x/pkgsite/internal/godoc.(*Package).Encode(ctx Context) (_ []byte, err error) func golang.org/x/pkgsite/internal/godoc.(*Package).Render(ctx Context, innerPath string, sourceInfo *source.Info, modInfo *godoc.ModuleInfo, nameToVersion map[string]string) (_ *dochtml.Parts, err error) func golang.org/x/pkgsite/internal/godoc/dochtml.Render(ctx Context, fset *token.FileSet, p *doc.Package, opt dochtml.RenderOptions) (_ *dochtml.Parts, err error) func golang.org/x/pkgsite/internal/godoc/dochtml/internal/render.New(ctx Context, fset *token.FileSet, pkg *doc.Package, opts *render.Options) *render.Renderer func golang.org/x/pkgsite/internal/index.(*Client).GetVersions(ctx Context, since time.Time, limit int) (_ []*internal.IndexVersion, err error) func golang.org/x/pkgsite/internal/localdatasource.(*DataSource).GetLatestInfo(ctx Context, unitPath, modulePath string, latestUnitMeta *internal.UnitMeta) (internal.LatestInfo, error) func golang.org/x/pkgsite/internal/localdatasource.(*DataSource).GetModuleReadme(ctx Context, modulePath, resolvedVersion string) (*internal.Readme, error) func golang.org/x/pkgsite/internal/localdatasource.(*DataSource).GetNestedModules(ctx Context, modulePath string) ([]*internal.ModuleInfo, error) func golang.org/x/pkgsite/internal/localdatasource.(*DataSource).GetUnit(ctx Context, pathInfo *internal.UnitMeta, fields internal.FieldSet, bc internal.BuildContext) (_ *internal.Unit, err error) func golang.org/x/pkgsite/internal/localdatasource.(*DataSource).GetUnitMeta(ctx Context, path, requestedModulePath, requestedVersion string) (_ *internal.UnitMeta, err error) func golang.org/x/pkgsite/internal/localdatasource.(*DataSource).Load(ctx Context, localPath string) (err error) func golang.org/x/pkgsite/internal/localdatasource.(*DataSource).LoadFromGOPATH(ctx Context, importPath string) (err error) func golang.org/x/pkgsite/internal/log.Debug(ctx Context, arg interface{}) func golang.org/x/pkgsite/internal/log.Debugf(ctx Context, format string, args ...interface{}) func golang.org/x/pkgsite/internal/log.Error(ctx Context, arg interface{}) func golang.org/x/pkgsite/internal/log.Errorf(ctx Context, format string, args ...interface{}) func golang.org/x/pkgsite/internal/log.Fatal(ctx Context, arg interface{}) func golang.org/x/pkgsite/internal/log.Fatalf(ctx Context, format string, args ...interface{}) func golang.org/x/pkgsite/internal/log.Info(ctx Context, arg interface{}) func golang.org/x/pkgsite/internal/log.Infof(ctx Context, format string, args ...interface{}) func golang.org/x/pkgsite/internal/log.NewContextWithLabel(ctx Context, key, value string) Context func golang.org/x/pkgsite/internal/log.NewContextWithTraceID(ctx Context, traceID string) Context func golang.org/x/pkgsite/internal/log.UseStackdriver(ctx Context, cfg *config.Config, logName string) (_ *logging.Logger, err error) func golang.org/x/pkgsite/internal/log.Warning(ctx Context, arg interface{}) func golang.org/x/pkgsite/internal/log.Warningf(ctx Context, format string, args ...interface{}) func golang.org/x/pkgsite/internal/middleware.ElapsedStat(ctx Context, name string) func() func golang.org/x/pkgsite/internal/middleware.NewExperimenter(ctx Context, pollEvery time.Duration, getter middleware.ExperimentGetter, rep middleware.Reporter) (_ *middleware.Experimenter, err error) func golang.org/x/pkgsite/internal/middleware.SetStat(ctx Context, key string, value interface{}) func golang.org/x/pkgsite/internal/poller.(*Poller).Poll(ctx Context) func golang.org/x/pkgsite/internal/poller.(*Poller).Start(ctx Context, period time.Duration) func golang.org/x/pkgsite/internal/postgres.GetFromSearchDocuments(ctx Context, t *testing.T, db *postgres.DB, packagePath string) (modulePath, version string, found bool) func golang.org/x/pkgsite/internal/postgres.GetPathID(ctx Context, ddb *database.DB, path string) (id int, err error) func golang.org/x/pkgsite/internal/postgres.GetSymbolHistoryForBuildContext(ctx Context, ddb *database.DB, pathID int, modulePath string, bc internal.BuildContext) (_ map[string]string, err error) func golang.org/x/pkgsite/internal/postgres.GetSymbolHistoryFromTable(ctx Context, ddb *database.DB, packagePath, modulePath string) (_ *internal.SymbolHistory, err error) func golang.org/x/pkgsite/internal/postgres.GetSymbolHistoryWithPackageSymbols(ctx Context, ddb *database.DB, packagePath, modulePath string) (_ *internal.SymbolHistory, err error) func golang.org/x/pkgsite/internal/postgres.InsertSampleDirectoryTree(ctx Context, t *testing.T, testDB *postgres.DB) func golang.org/x/pkgsite/internal/postgres.MustInsertModule(ctx Context, t *testing.T, db *postgres.DB, m *internal.Module) func golang.org/x/pkgsite/internal/postgres.MustInsertModuleGoMod(ctx Context, t *testing.T, db *postgres.DB, m *internal.Module, goMod string) func golang.org/x/pkgsite/internal/postgres.MustInsertModuleNotLatest(ctx Context, t *testing.T, db *postgres.DB, m *internal.Module) func golang.org/x/pkgsite/internal/postgres.UpsertSearchDocument(ctx Context, ddb *database.DB, args postgres.UpsertSearchDocumentArgs) (err error) func golang.org/x/pkgsite/internal/postgres.(*DB).CleanModule(ctx Context, modulePath, reason string) (err error) func golang.org/x/pkgsite/internal/postgres.(*DB).CleanModuleVersions(ctx Context, mvs []postgres.ModuleVersion, reason string) (err error) func golang.org/x/pkgsite/internal/postgres.(*DB).DeleteModule(ctx Context, modulePath, resolvedVersion string) (err error) func golang.org/x/pkgsite/internal/postgres.(*DB).DeleteOlderVersionFromSearchDocuments(ctx Context, modulePath, resolvedVersion string) (err error) func golang.org/x/pkgsite/internal/postgres.(*DB).DeletePseudoversionsExcept(ctx Context, modulePath, resolvedVersion string) (err error) func golang.org/x/pkgsite/internal/postgres.(*DB).GetExcludedPrefixes(ctx Context) ([]string, error) func golang.org/x/pkgsite/internal/postgres.(*DB).GetImportedBy(ctx Context, pkgPath, modulePath string, limit int) (paths []string, err error) func golang.org/x/pkgsite/internal/postgres.(*DB).GetImportedByCount(ctx Context, pkgPath, modulePath string) (_ int, err error) func golang.org/x/pkgsite/internal/postgres.(*DB).GetLatestInfo(ctx Context, unitPath, modulePath string, latestUnitMeta *internal.UnitMeta) (latest internal.LatestInfo, err error) func golang.org/x/pkgsite/internal/postgres.(*DB).GetLatestMajorPathForV1Path(ctx Context, v1path string) (_ string, _ int, err error) func golang.org/x/pkgsite/internal/postgres.(*DB).GetLatestModuleVersions(ctx Context, modulePath string) (_ *internal.LatestModuleVersions, err error) func golang.org/x/pkgsite/internal/postgres.(*DB).GetModuleInfo(ctx Context, modulePath, resolvedVersion string) (_ *internal.ModuleInfo, err error) func golang.org/x/pkgsite/internal/postgres.(*DB).GetModuleReadme(ctx Context, modulePath, resolvedVersion string) (_ *internal.Readme, err error) func golang.org/x/pkgsite/internal/postgres.(*DB).GetModuleVersionState(ctx Context, modulePath, resolvedVersion string) (_ *internal.ModuleVersionState, err error) func golang.org/x/pkgsite/internal/postgres.(*DB).GetModuleVersionsToClean(ctx Context, daysOld, limit int) (modvers []postgres.ModuleVersion, err error) func golang.org/x/pkgsite/internal/postgres.(*DB).GetNestedModules(ctx Context, modulePath string) (_ []*internal.ModuleInfo, err error) func golang.org/x/pkgsite/internal/postgres.(*DB).GetNextModulesToFetch(ctx Context, limit int) (_ []*internal.ModuleVersionState, err error) func golang.org/x/pkgsite/internal/postgres.(*DB).GetPackagesForSearchDocumentUpsert(ctx Context, before time.Time, limit int) (argsList []postgres.UpsertSearchDocumentArgs, err error) func golang.org/x/pkgsite/internal/postgres.(*DB).GetPackageVersionState(ctx Context, pkgPath, modulePath, resolvedVersion string) (_ *internal.PackageVersionState, err error) func golang.org/x/pkgsite/internal/postgres.(*DB).GetPackageVersionStatesForModule(ctx Context, modulePath, resolvedVersion string) (_ []*internal.PackageVersionState, err error) func golang.org/x/pkgsite/internal/postgres.(*DB).GetRecentFailedVersions(ctx Context, limit int) (_ []*internal.ModuleVersionState, err error) func golang.org/x/pkgsite/internal/postgres.(*DB).GetRecentVersions(ctx Context, limit int) (_ []*internal.ModuleVersionState, err error) func golang.org/x/pkgsite/internal/postgres.(*DB).GetStdlibPathsWithSuffix(ctx Context, suffix string) (paths []string, err error) func golang.org/x/pkgsite/internal/postgres.(*DB).GetSymbolHistory(ctx Context, packagePath, modulePath string) (_ *internal.SymbolHistory, err error) func golang.org/x/pkgsite/internal/postgres.(*DB).GetUnit(ctx Context, um *internal.UnitMeta, fields internal.FieldSet, bc internal.BuildContext) (_ *internal.Unit, err error) func golang.org/x/pkgsite/internal/postgres.(*DB).GetUnitMeta(ctx Context, fullPath, requestedModulePath, requestedVersion string) (_ *internal.UnitMeta, err error) func golang.org/x/pkgsite/internal/postgres.(*DB).GetVersionMap(ctx Context, modulePath, requestedVersion string) (_ *internal.VersionMap, err error) func golang.org/x/pkgsite/internal/postgres.(*DB).GetVersionMaps(ctx Context, paths []string, requestedVersion string) (_ []*internal.VersionMap, err error) func golang.org/x/pkgsite/internal/postgres.(*DB).GetVersionsForPath(ctx Context, path string) (_ []*internal.ModuleInfo, err error) func golang.org/x/pkgsite/internal/postgres.(*DB).GetVersionStats(ctx Context) (_ *postgres.VersionStats, err error) func golang.org/x/pkgsite/internal/postgres.(*DB).HasGoMod(ctx Context, modulePath, version string) (has bool, err error) func golang.org/x/pkgsite/internal/postgres.(*DB).InsertExcludedPrefix(ctx Context, prefix, user, reason string) (err error) func golang.org/x/pkgsite/internal/postgres.(*DB).InsertIndexVersions(ctx Context, versions []*internal.IndexVersion) (err error) func golang.org/x/pkgsite/internal/postgres.(*DB).InsertModule(ctx Context, m *internal.Module, lmv *internal.LatestModuleVersions) (isLatest bool, err error) func golang.org/x/pkgsite/internal/postgres.(*DB).IsExcluded(ctx Context, path string) (_ bool, err error) func golang.org/x/pkgsite/internal/postgres.(*DB).LatestIndexTimestamp(ctx Context) (_ time.Time, err error) func golang.org/x/pkgsite/internal/postgres.(*DB).ReInsertLatestVersion(ctx Context, modulePath string) (err error) func golang.org/x/pkgsite/internal/postgres.(*DB).Search(ctx Context, q string, limit, offset, maxResultCount int, searchSymbols bool) (_ []*internal.SearchResult, err error) func golang.org/x/pkgsite/internal/postgres.(*DB).StalenessTimestamp(ctx Context) (time.Time, error) func golang.org/x/pkgsite/internal/postgres.(*DB).UpdateLatestModuleVersions(ctx Context, vNew *internal.LatestModuleVersions) (_ *internal.LatestModuleVersions, err error) func golang.org/x/pkgsite/internal/postgres.(*DB).UpdateLatestModuleVersionsStatus(ctx Context, modulePath string, newStatus int) (err error) func golang.org/x/pkgsite/internal/postgres.(*DB).UpdateModuleVersionStatesForReprocessing(ctx Context, appVersion string) (err error) func golang.org/x/pkgsite/internal/postgres.(*DB).UpdateModuleVersionStatesForReprocessingLatestOnly(ctx Context, appVersion string) (err error) func golang.org/x/pkgsite/internal/postgres.(*DB).UpdateModuleVersionStatesForReprocessingReleaseVersionsOnly(ctx Context, appVersion string) (err error) func golang.org/x/pkgsite/internal/postgres.(*DB).UpdateModuleVersionStatesWithStatus(ctx Context, status int, appVersion string) (err error) func golang.org/x/pkgsite/internal/postgres.(*DB).UpdateModuleVersionStatus(ctx Context, modulePath, version string, status int, error string) (err error) func golang.org/x/pkgsite/internal/postgres.(*DB).UpdateSearchDocumentsImportedByCount(ctx Context) (nUpdated int64, err error) func golang.org/x/pkgsite/internal/postgres.(*DB).UpsertModuleVersionState(ctx Context, mvs *postgres.ModuleVersionStateForUpsert) (err error) func golang.org/x/pkgsite/internal/postgres.(*DB).UpsertSearchDocumentWithImportedByCount(ctx Context, args postgres.UpsertSearchDocumentArgs, importedByCount int) (err error) func golang.org/x/pkgsite/internal/postgres.(*DB).UpsertVersionMap(ctx Context, vm *internal.VersionMap) (err error) func golang.org/x/pkgsite/internal/proxy.(*Client).Info(ctx Context, modulePath, requestedVersion string) (_ *proxy.VersionInfo, err error) func golang.org/x/pkgsite/internal/proxy.(*Client).Mod(ctx Context, modulePath, resolvedVersion string) (_ []byte, err error) func golang.org/x/pkgsite/internal/proxy.(*Client).Versions(ctx Context, modulePath string) (_ []string, err error) func golang.org/x/pkgsite/internal/proxy.(*Client).Zip(ctx Context, modulePath, resolvedVersion string) (_ *zip.Reader, err error) func golang.org/x/pkgsite/internal/proxy.(*Client).ZipSize(ctx Context, modulePath, resolvedVersion string) (_ int64, err error) func golang.org/x/pkgsite/internal/proxydatasource.(*DataSource).GetExperiments(ctx Context) ([]*internal.Experiment, error) func golang.org/x/pkgsite/internal/proxydatasource.(*DataSource).GetLatestInfo(ctx Context, unitPath, modulePath string, latestUnitMeta *internal.UnitMeta) (latest internal.LatestInfo, err error) func golang.org/x/pkgsite/internal/proxydatasource.(*DataSource).GetModuleInfo(ctx Context, modulePath, version string) (_ *internal.ModuleInfo, err error) func golang.org/x/pkgsite/internal/proxydatasource.(*DataSource).GetModuleReadme(ctx Context, modulePath, resolvedVersion string) (*internal.Readme, error) func golang.org/x/pkgsite/internal/proxydatasource.(*DataSource).GetNestedModules(ctx Context, modulePath string) (_ []*internal.ModuleInfo, err error) func golang.org/x/pkgsite/internal/proxydatasource.(*DataSource).GetUnit(ctx Context, um *internal.UnitMeta, field internal.FieldSet, bc internal.BuildContext) (_ *internal.Unit, err error) func golang.org/x/pkgsite/internal/proxydatasource.(*DataSource).GetUnitMeta(ctx Context, path, inModulePath, inVersion string) (_ *internal.UnitMeta, err error) func golang.org/x/pkgsite/internal/queue.New(ctx Context, cfg *config.Config, queueName string, numWorkers int, expGetter middleware.ExperimentGetter, processFunc queue.inMemoryProcessFunc) (queue.Queue, error) func golang.org/x/pkgsite/internal/queue.NewInMemory(ctx Context, workerCount int, experiments []string, processFunc queue.inMemoryProcessFunc) *queue.InMemory func golang.org/x/pkgsite/internal/queue.(*GCP).ScheduleFetch(ctx Context, modulePath, version, suffix string, disableProxyFetch bool) (enqueued bool, err error) func golang.org/x/pkgsite/internal/queue.(*InMemory).ScheduleFetch(ctx Context, modulePath, version, _ string, _ bool) (bool, error) func golang.org/x/pkgsite/internal/queue.InMemory.WaitForTesting(ctx Context) func golang.org/x/pkgsite/internal/queue.Queue.ScheduleFetch(ctx Context, modulePath, version, suffix string, disableProxyFetch bool) (bool, error) func golang.org/x/pkgsite/internal/secrets.Get(ctx Context, name string) (plaintext string, err error) func golang.org/x/pkgsite/internal/source.ModuleInfo(ctx Context, client *source.Client, modulePath, version string) (info *source.Info, err error) func golang.org/x/pkgsite/internal/worker.(*Fetcher).FetchAndUpdateLatest(ctx Context, modulePath string) (_ *internal.LatestModuleVersions, err error) func golang.org/x/pkgsite/internal/worker.(*Fetcher).FetchAndUpdateState(ctx Context, modulePath, requestedVersion, appVersionLabel string) (_ int, resolvedVersion string, err error) func golang.org/x/pkgsite/internal/xcontext.Detach(ctx Context) Context func golang.org/x/sync/errgroup.WithContext(ctx Context) (*errgroup.Group, Context) func golang.org/x/sync/semaphore.(*Weighted).Acquire(ctx Context, n int64) error func google.golang.org/api/idtoken.NewClient(ctx Context, audience string, opts ...idtoken.ClientOption) (*http.Client, error) func google.golang.org/api/idtoken.NewTokenSource(ctx Context, audience string, opts ...idtoken.ClientOption) (oauth2.TokenSource, error) func google.golang.org/api/idtoken.NewValidator(ctx Context, opts ...idtoken.ClientOption) (*idtoken.Validator, error) func google.golang.org/api/idtoken.Validate(ctx Context, idToken string, audience string) (*idtoken.Payload, error) func google.golang.org/api/idtoken.(*Validator).Validate(ctx Context, idToken string, audience string) (*idtoken.Payload, error) func google.golang.org/api/internal.Creds(ctx Context, ds *internal.DialSettings) (*google.Credentials, error) func google.golang.org/api/internal.ConnPool.Invoke(ctx Context, method string, args interface{}, reply interface{}, opts ...grpc.CallOption) error func google.golang.org/api/internal.ConnPool.NewStream(ctx Context, desc *grpc.StreamDesc, method string, opts ...grpc.CallOption) (grpc.ClientStream, error) func google.golang.org/api/internal/gensupport.SendRequest(ctx Context, client *http.Client, req *http.Request) (*http.Response, error) func google.golang.org/api/internal/gensupport.SendRequestWithRetry(ctx Context, client *http.Client, req *http.Request) (*http.Response, error) func google.golang.org/api/internal/gensupport.(*ResumableUpload).Upload(ctx Context) (resp *http.Response, err error) func google.golang.org/api/internal/impersonate.TokenSource(ctx Context, ts oauth2.TokenSource, config *impersonate.Config) (oauth2.TokenSource, error) func google.golang.org/api/storage/v1.NewService(ctx Context, opts ...option.ClientOption) (*storage.Service, error) func google.golang.org/api/storage/v1.(*BucketAccessControlsDeleteCall).Context(ctx Context) *storage.BucketAccessControlsDeleteCall func google.golang.org/api/storage/v1.(*BucketAccessControlsGetCall).Context(ctx Context) *storage.BucketAccessControlsGetCall func google.golang.org/api/storage/v1.(*BucketAccessControlsInsertCall).Context(ctx Context) *storage.BucketAccessControlsInsertCall func google.golang.org/api/storage/v1.(*BucketAccessControlsListCall).Context(ctx Context) *storage.BucketAccessControlsListCall func google.golang.org/api/storage/v1.(*BucketAccessControlsPatchCall).Context(ctx Context) *storage.BucketAccessControlsPatchCall func google.golang.org/api/storage/v1.(*BucketAccessControlsUpdateCall).Context(ctx Context) *storage.BucketAccessControlsUpdateCall func google.golang.org/api/storage/v1.(*BucketsDeleteCall).Context(ctx Context) *storage.BucketsDeleteCall func google.golang.org/api/storage/v1.(*BucketsGetCall).Context(ctx Context) *storage.BucketsGetCall func google.golang.org/api/storage/v1.(*BucketsGetIamPolicyCall).Context(ctx Context) *storage.BucketsGetIamPolicyCall func google.golang.org/api/storage/v1.(*BucketsInsertCall).Context(ctx Context) *storage.BucketsInsertCall func google.golang.org/api/storage/v1.(*BucketsListCall).Context(ctx Context) *storage.BucketsListCall func google.golang.org/api/storage/v1.(*BucketsListCall).Pages(ctx Context, f func(*storage.Buckets) error) error func google.golang.org/api/storage/v1.(*BucketsLockRetentionPolicyCall).Context(ctx Context) *storage.BucketsLockRetentionPolicyCall func google.golang.org/api/storage/v1.(*BucketsPatchCall).Context(ctx Context) *storage.BucketsPatchCall func google.golang.org/api/storage/v1.(*BucketsSetIamPolicyCall).Context(ctx Context) *storage.BucketsSetIamPolicyCall func google.golang.org/api/storage/v1.(*BucketsTestIamPermissionsCall).Context(ctx Context) *storage.BucketsTestIamPermissionsCall func google.golang.org/api/storage/v1.(*BucketsUpdateCall).Context(ctx Context) *storage.BucketsUpdateCall func google.golang.org/api/storage/v1.(*ChannelsStopCall).Context(ctx Context) *storage.ChannelsStopCall func google.golang.org/api/storage/v1.(*DefaultObjectAccessControlsDeleteCall).Context(ctx Context) *storage.DefaultObjectAccessControlsDeleteCall func google.golang.org/api/storage/v1.(*DefaultObjectAccessControlsGetCall).Context(ctx Context) *storage.DefaultObjectAccessControlsGetCall func google.golang.org/api/storage/v1.(*DefaultObjectAccessControlsInsertCall).Context(ctx Context) *storage.DefaultObjectAccessControlsInsertCall func google.golang.org/api/storage/v1.(*DefaultObjectAccessControlsListCall).Context(ctx Context) *storage.DefaultObjectAccessControlsListCall func google.golang.org/api/storage/v1.(*DefaultObjectAccessControlsPatchCall).Context(ctx Context) *storage.DefaultObjectAccessControlsPatchCall func google.golang.org/api/storage/v1.(*DefaultObjectAccessControlsUpdateCall).Context(ctx Context) *storage.DefaultObjectAccessControlsUpdateCall func google.golang.org/api/storage/v1.(*NotificationsDeleteCall).Context(ctx Context) *storage.NotificationsDeleteCall func google.golang.org/api/storage/v1.(*NotificationsGetCall).Context(ctx Context) *storage.NotificationsGetCall func google.golang.org/api/storage/v1.(*NotificationsInsertCall).Context(ctx Context) *storage.NotificationsInsertCall func google.golang.org/api/storage/v1.(*NotificationsListCall).Context(ctx Context) *storage.NotificationsListCall func google.golang.org/api/storage/v1.(*ObjectAccessControlsDeleteCall).Context(ctx Context) *storage.ObjectAccessControlsDeleteCall func google.golang.org/api/storage/v1.(*ObjectAccessControlsGetCall).Context(ctx Context) *storage.ObjectAccessControlsGetCall func google.golang.org/api/storage/v1.(*ObjectAccessControlsInsertCall).Context(ctx Context) *storage.ObjectAccessControlsInsertCall func google.golang.org/api/storage/v1.(*ObjectAccessControlsListCall).Context(ctx Context) *storage.ObjectAccessControlsListCall func google.golang.org/api/storage/v1.(*ObjectAccessControlsPatchCall).Context(ctx Context) *storage.ObjectAccessControlsPatchCall func google.golang.org/api/storage/v1.(*ObjectAccessControlsUpdateCall).Context(ctx Context) *storage.ObjectAccessControlsUpdateCall func google.golang.org/api/storage/v1.(*ObjectsComposeCall).Context(ctx Context) *storage.ObjectsComposeCall func google.golang.org/api/storage/v1.(*ObjectsCopyCall).Context(ctx Context) *storage.ObjectsCopyCall func google.golang.org/api/storage/v1.(*ObjectsDeleteCall).Context(ctx Context) *storage.ObjectsDeleteCall func google.golang.org/api/storage/v1.(*ObjectsGetCall).Context(ctx Context) *storage.ObjectsGetCall func google.golang.org/api/storage/v1.(*ObjectsGetIamPolicyCall).Context(ctx Context) *storage.ObjectsGetIamPolicyCall func google.golang.org/api/storage/v1.(*ObjectsInsertCall).Context(ctx Context) *storage.ObjectsInsertCall func google.golang.org/api/storage/v1.(*ObjectsInsertCall).ResumableMedia(ctx Context, r io.ReaderAt, size int64, mediaType string) *storage.ObjectsInsertCall func google.golang.org/api/storage/v1.(*ObjectsListCall).Context(ctx Context) *storage.ObjectsListCall func google.golang.org/api/storage/v1.(*ObjectsListCall).Pages(ctx Context, f func(*storage.Objects) error) error func google.golang.org/api/storage/v1.(*ObjectsPatchCall).Context(ctx Context) *storage.ObjectsPatchCall func google.golang.org/api/storage/v1.(*ObjectsRewriteCall).Context(ctx Context) *storage.ObjectsRewriteCall func google.golang.org/api/storage/v1.(*ObjectsSetIamPolicyCall).Context(ctx Context) *storage.ObjectsSetIamPolicyCall func google.golang.org/api/storage/v1.(*ObjectsTestIamPermissionsCall).Context(ctx Context) *storage.ObjectsTestIamPermissionsCall func google.golang.org/api/storage/v1.(*ObjectsUpdateCall).Context(ctx Context) *storage.ObjectsUpdateCall func google.golang.org/api/storage/v1.(*ObjectsWatchAllCall).Context(ctx Context) *storage.ObjectsWatchAllCall func google.golang.org/api/storage/v1.(*ProjectsHmacKeysCreateCall).Context(ctx Context) *storage.ProjectsHmacKeysCreateCall func google.golang.org/api/storage/v1.(*ProjectsHmacKeysDeleteCall).Context(ctx Context) *storage.ProjectsHmacKeysDeleteCall func google.golang.org/api/storage/v1.(*ProjectsHmacKeysGetCall).Context(ctx Context) *storage.ProjectsHmacKeysGetCall func google.golang.org/api/storage/v1.(*ProjectsHmacKeysListCall).Context(ctx Context) *storage.ProjectsHmacKeysListCall func google.golang.org/api/storage/v1.(*ProjectsHmacKeysListCall).Pages(ctx Context, f func(*storage.HmacKeysMetadata) error) error func google.golang.org/api/storage/v1.(*ProjectsHmacKeysUpdateCall).Context(ctx Context) *storage.ProjectsHmacKeysUpdateCall func google.golang.org/api/storage/v1.(*ProjectsServiceAccountGetCall).Context(ctx Context) *storage.ProjectsServiceAccountGetCall func google.golang.org/api/support/bundler.(*Bundler).AddWait(ctx Context, item interface{}, size int) error func google.golang.org/api/transport.Creds(ctx Context, opts ...option.ClientOption) (*google.Credentials, error) func google.golang.org/api/transport.DialGRPC(ctx Context, opts ...option.ClientOption) (*grpc.ClientConn, error) func google.golang.org/api/transport.DialGRPCInsecure(ctx Context, opts ...option.ClientOption) (*grpc.ClientConn, error) func google.golang.org/api/transport.NewHTTPClient(ctx Context, opts ...option.ClientOption) (*http.Client, string, error) func google.golang.org/api/transport/grpc.Dial(ctx Context, opts ...option.ClientOption) (*grpc.ClientConn, error) func google.golang.org/api/transport/grpc.DialInsecure(ctx Context, opts ...option.ClientOption) (*grpc.ClientConn, error) func google.golang.org/api/transport/grpc.DialPool(ctx Context, opts ...option.ClientOption) (grpc.ConnPool, error) func google.golang.org/api/transport/grpc.ConnPool.Invoke(ctx Context, method string, args interface{}, reply interface{}, opts ...grpc.CallOption) error func google.golang.org/api/transport/grpc.ConnPool.NewStream(ctx Context, desc *grpc.StreamDesc, method string, opts ...grpc.CallOption) (grpc.ClientStream, error) func google.golang.org/api/transport/http.NewClient(ctx Context, opts ...option.ClientOption) (*http.Client, string, error) func google.golang.org/api/transport/http.NewTransport(ctx Context, base http.RoundTripper, opts ...option.ClientOption) (http.RoundTripper, error) func google.golang.org/genproto/googleapis/cloud/secretmanager/v1.SecretManagerServiceClient.AccessSecretVersion(ctx Context, in *secretmanager.AccessSecretVersionRequest, opts ...grpc.CallOption) (*secretmanager.AccessSecretVersionResponse, error) func google.golang.org/genproto/googleapis/cloud/secretmanager/v1.SecretManagerServiceClient.AddSecretVersion(ctx Context, in *secretmanager.AddSecretVersionRequest, opts ...grpc.CallOption) (*secretmanager.SecretVersion, error) func google.golang.org/genproto/googleapis/cloud/secretmanager/v1.SecretManagerServiceClient.CreateSecret(ctx Context, in *secretmanager.CreateSecretRequest, opts ...grpc.CallOption) (*secretmanager.Secret, error) func google.golang.org/genproto/googleapis/cloud/secretmanager/v1.SecretManagerServiceClient.DeleteSecret(ctx Context, in *secretmanager.DeleteSecretRequest, opts ...grpc.CallOption) (*emptypb.Empty, error) func google.golang.org/genproto/googleapis/cloud/secretmanager/v1.SecretManagerServiceClient.DestroySecretVersion(ctx Context, in *secretmanager.DestroySecretVersionRequest, opts ...grpc.CallOption) (*secretmanager.SecretVersion, error) func google.golang.org/genproto/googleapis/cloud/secretmanager/v1.SecretManagerServiceClient.DisableSecretVersion(ctx Context, in *secretmanager.DisableSecretVersionRequest, opts ...grpc.CallOption) (*secretmanager.SecretVersion, error) func google.golang.org/genproto/googleapis/cloud/secretmanager/v1.SecretManagerServiceClient.EnableSecretVersion(ctx Context, in *secretmanager.EnableSecretVersionRequest, opts ...grpc.CallOption) (*secretmanager.SecretVersion, error) func google.golang.org/genproto/googleapis/cloud/secretmanager/v1.SecretManagerServiceClient.GetIamPolicy(ctx Context, in *v1.GetIamPolicyRequest, opts ...grpc.CallOption) (*v1.Policy, error) func google.golang.org/genproto/googleapis/cloud/secretmanager/v1.SecretManagerServiceClient.GetSecret(ctx Context, in *secretmanager.GetSecretRequest, opts ...grpc.CallOption) (*secretmanager.Secret, error) func google.golang.org/genproto/googleapis/cloud/secretmanager/v1.SecretManagerServiceClient.GetSecretVersion(ctx Context, in *secretmanager.GetSecretVersionRequest, opts ...grpc.CallOption) (*secretmanager.SecretVersion, error) func google.golang.org/genproto/googleapis/cloud/secretmanager/v1.SecretManagerServiceClient.ListSecrets(ctx Context, in *secretmanager.ListSecretsRequest, opts ...grpc.CallOption) (*secretmanager.ListSecretsResponse, error) func google.golang.org/genproto/googleapis/cloud/secretmanager/v1.SecretManagerServiceClient.ListSecretVersions(ctx Context, in *secretmanager.ListSecretVersionsRequest, opts ...grpc.CallOption) (*secretmanager.ListSecretVersionsResponse, error) func google.golang.org/genproto/googleapis/cloud/secretmanager/v1.SecretManagerServiceClient.SetIamPolicy(ctx Context, in *v1.SetIamPolicyRequest, opts ...grpc.CallOption) (*v1.Policy, error) func google.golang.org/genproto/googleapis/cloud/secretmanager/v1.SecretManagerServiceClient.TestIamPermissions(ctx Context, in *v1.TestIamPermissionsRequest, opts ...grpc.CallOption) (*v1.TestIamPermissionsResponse, error) func google.golang.org/genproto/googleapis/cloud/secretmanager/v1.SecretManagerServiceClient.UpdateSecret(ctx Context, in *secretmanager.UpdateSecretRequest, opts ...grpc.CallOption) (*secretmanager.Secret, error) func google.golang.org/genproto/googleapis/cloud/secretmanager/v1.SecretManagerServiceServer.AccessSecretVersion(Context, *secretmanager.AccessSecretVersionRequest) (*secretmanager.AccessSecretVersionResponse, error) func google.golang.org/genproto/googleapis/cloud/secretmanager/v1.SecretManagerServiceServer.AddSecretVersion(Context, *secretmanager.AddSecretVersionRequest) (*secretmanager.SecretVersion, error) func google.golang.org/genproto/googleapis/cloud/secretmanager/v1.SecretManagerServiceServer.CreateSecret(Context, *secretmanager.CreateSecretRequest) (*secretmanager.Secret, error) func google.golang.org/genproto/googleapis/cloud/secretmanager/v1.SecretManagerServiceServer.DeleteSecret(Context, *secretmanager.DeleteSecretRequest) (*emptypb.Empty, error) func google.golang.org/genproto/googleapis/cloud/secretmanager/v1.SecretManagerServiceServer.DestroySecretVersion(Context, *secretmanager.DestroySecretVersionRequest) (*secretmanager.SecretVersion, error) func google.golang.org/genproto/googleapis/cloud/secretmanager/v1.SecretManagerServiceServer.DisableSecretVersion(Context, *secretmanager.DisableSecretVersionRequest) (*secretmanager.SecretVersion, error) func google.golang.org/genproto/googleapis/cloud/secretmanager/v1.SecretManagerServiceServer.EnableSecretVersion(Context, *secretmanager.EnableSecretVersionRequest) (*secretmanager.SecretVersion, error) func google.golang.org/genproto/googleapis/cloud/secretmanager/v1.SecretManagerServiceServer.GetIamPolicy(Context, *v1.GetIamPolicyRequest) (*v1.Policy, error) func google.golang.org/genproto/googleapis/cloud/secretmanager/v1.SecretManagerServiceServer.GetSecret(Context, *secretmanager.GetSecretRequest) (*secretmanager.Secret, error) func google.golang.org/genproto/googleapis/cloud/secretmanager/v1.SecretManagerServiceServer.GetSecretVersion(Context, *secretmanager.GetSecretVersionRequest) (*secretmanager.SecretVersion, error) func google.golang.org/genproto/googleapis/cloud/secretmanager/v1.SecretManagerServiceServer.ListSecrets(Context, *secretmanager.ListSecretsRequest) (*secretmanager.ListSecretsResponse, error) func google.golang.org/genproto/googleapis/cloud/secretmanager/v1.SecretManagerServiceServer.ListSecretVersions(Context, *secretmanager.ListSecretVersionsRequest) (*secretmanager.ListSecretVersionsResponse, error) func google.golang.org/genproto/googleapis/cloud/secretmanager/v1.SecretManagerServiceServer.SetIamPolicy(Context, *v1.SetIamPolicyRequest) (*v1.Policy, error) func google.golang.org/genproto/googleapis/cloud/secretmanager/v1.SecretManagerServiceServer.TestIamPermissions(Context, *v1.TestIamPermissionsRequest) (*v1.TestIamPermissionsResponse, error) func google.golang.org/genproto/googleapis/cloud/secretmanager/v1.SecretManagerServiceServer.UpdateSecret(Context, *secretmanager.UpdateSecretRequest) (*secretmanager.Secret, error) func google.golang.org/genproto/googleapis/cloud/secretmanager/v1.(*UnimplementedSecretManagerServiceServer).AccessSecretVersion(Context, *secretmanager.AccessSecretVersionRequest) (*secretmanager.AccessSecretVersionResponse, error) func google.golang.org/genproto/googleapis/cloud/secretmanager/v1.(*UnimplementedSecretManagerServiceServer).AddSecretVersion(Context, *secretmanager.AddSecretVersionRequest) (*secretmanager.SecretVersion, error) func google.golang.org/genproto/googleapis/cloud/secretmanager/v1.(*UnimplementedSecretManagerServiceServer).CreateSecret(Context, *secretmanager.CreateSecretRequest) (*secretmanager.Secret, error) func google.golang.org/genproto/googleapis/cloud/secretmanager/v1.(*UnimplementedSecretManagerServiceServer).DeleteSecret(Context, *secretmanager.DeleteSecretRequest) (*emptypb.Empty, error) func google.golang.org/genproto/googleapis/cloud/secretmanager/v1.(*UnimplementedSecretManagerServiceServer).DestroySecretVersion(Context, *secretmanager.DestroySecretVersionRequest) (*secretmanager.SecretVersion, error) func google.golang.org/genproto/googleapis/cloud/secretmanager/v1.(*UnimplementedSecretManagerServiceServer).DisableSecretVersion(Context, *secretmanager.DisableSecretVersionRequest) (*secretmanager.SecretVersion, error) func google.golang.org/genproto/googleapis/cloud/secretmanager/v1.(*UnimplementedSecretManagerServiceServer).EnableSecretVersion(Context, *secretmanager.EnableSecretVersionRequest) (*secretmanager.SecretVersion, error) func google.golang.org/genproto/googleapis/cloud/secretmanager/v1.(*UnimplementedSecretManagerServiceServer).GetIamPolicy(Context, *v1.GetIamPolicyRequest) (*v1.Policy, error) func google.golang.org/genproto/googleapis/cloud/secretmanager/v1.(*UnimplementedSecretManagerServiceServer).GetSecret(Context, *secretmanager.GetSecretRequest) (*secretmanager.Secret, error) func google.golang.org/genproto/googleapis/cloud/secretmanager/v1.(*UnimplementedSecretManagerServiceServer).GetSecretVersion(Context, *secretmanager.GetSecretVersionRequest) (*secretmanager.SecretVersion, error) func google.golang.org/genproto/googleapis/cloud/secretmanager/v1.(*UnimplementedSecretManagerServiceServer).ListSecrets(Context, *secretmanager.ListSecretsRequest) (*secretmanager.ListSecretsResponse, error) func google.golang.org/genproto/googleapis/cloud/secretmanager/v1.(*UnimplementedSecretManagerServiceServer).ListSecretVersions(Context, *secretmanager.ListSecretVersionsRequest) (*secretmanager.ListSecretVersionsResponse, error) func google.golang.org/genproto/googleapis/cloud/secretmanager/v1.(*UnimplementedSecretManagerServiceServer).SetIamPolicy(Context, *v1.SetIamPolicyRequest) (*v1.Policy, error) func google.golang.org/genproto/googleapis/cloud/secretmanager/v1.(*UnimplementedSecretManagerServiceServer).TestIamPermissions(Context, *v1.TestIamPermissionsRequest) (*v1.TestIamPermissionsResponse, error) func google.golang.org/genproto/googleapis/cloud/secretmanager/v1.(*UnimplementedSecretManagerServiceServer).UpdateSecret(Context, *secretmanager.UpdateSecretRequest) (*secretmanager.Secret, error) func google.golang.org/genproto/googleapis/cloud/tasks/v2.CloudTasksClient.CreateQueue(ctx Context, in *tasks.CreateQueueRequest, opts ...grpc.CallOption) (*tasks.Queue, error) func google.golang.org/genproto/googleapis/cloud/tasks/v2.CloudTasksClient.CreateTask(ctx Context, in *tasks.CreateTaskRequest, opts ...grpc.CallOption) (*tasks.Task, error) func google.golang.org/genproto/googleapis/cloud/tasks/v2.CloudTasksClient.DeleteQueue(ctx Context, in *tasks.DeleteQueueRequest, opts ...grpc.CallOption) (*emptypb.Empty, error) func google.golang.org/genproto/googleapis/cloud/tasks/v2.CloudTasksClient.DeleteTask(ctx Context, in *tasks.DeleteTaskRequest, opts ...grpc.CallOption) (*emptypb.Empty, error) func google.golang.org/genproto/googleapis/cloud/tasks/v2.CloudTasksClient.GetIamPolicy(ctx Context, in *v1.GetIamPolicyRequest, opts ...grpc.CallOption) (*v1.Policy, error) func google.golang.org/genproto/googleapis/cloud/tasks/v2.CloudTasksClient.GetQueue(ctx Context, in *tasks.GetQueueRequest, opts ...grpc.CallOption) (*tasks.Queue, error) func google.golang.org/genproto/googleapis/cloud/tasks/v2.CloudTasksClient.GetTask(ctx Context, in *tasks.GetTaskRequest, opts ...grpc.CallOption) (*tasks.Task, error) func google.golang.org/genproto/googleapis/cloud/tasks/v2.CloudTasksClient.ListQueues(ctx Context, in *tasks.ListQueuesRequest, opts ...grpc.CallOption) (*tasks.ListQueuesResponse, error) func google.golang.org/genproto/googleapis/cloud/tasks/v2.CloudTasksClient.ListTasks(ctx Context, in *tasks.ListTasksRequest, opts ...grpc.CallOption) (*tasks.ListTasksResponse, error) func google.golang.org/genproto/googleapis/cloud/tasks/v2.CloudTasksClient.PauseQueue(ctx Context, in *tasks.PauseQueueRequest, opts ...grpc.CallOption) (*tasks.Queue, error) func google.golang.org/genproto/googleapis/cloud/tasks/v2.CloudTasksClient.PurgeQueue(ctx Context, in *tasks.PurgeQueueRequest, opts ...grpc.CallOption) (*tasks.Queue, error) func google.golang.org/genproto/googleapis/cloud/tasks/v2.CloudTasksClient.ResumeQueue(ctx Context, in *tasks.ResumeQueueRequest, opts ...grpc.CallOption) (*tasks.Queue, error) func google.golang.org/genproto/googleapis/cloud/tasks/v2.CloudTasksClient.RunTask(ctx Context, in *tasks.RunTaskRequest, opts ...grpc.CallOption) (*tasks.Task, error) func google.golang.org/genproto/googleapis/cloud/tasks/v2.CloudTasksClient.SetIamPolicy(ctx Context, in *v1.SetIamPolicyRequest, opts ...grpc.CallOption) (*v1.Policy, error) func google.golang.org/genproto/googleapis/cloud/tasks/v2.CloudTasksClient.TestIamPermissions(ctx Context, in *v1.TestIamPermissionsRequest, opts ...grpc.CallOption) (*v1.TestIamPermissionsResponse, error) func google.golang.org/genproto/googleapis/cloud/tasks/v2.CloudTasksClient.UpdateQueue(ctx Context, in *tasks.UpdateQueueRequest, opts ...grpc.CallOption) (*tasks.Queue, error) func google.golang.org/genproto/googleapis/cloud/tasks/v2.CloudTasksServer.CreateQueue(Context, *tasks.CreateQueueRequest) (*tasks.Queue, error) func google.golang.org/genproto/googleapis/cloud/tasks/v2.CloudTasksServer.CreateTask(Context, *tasks.CreateTaskRequest) (*tasks.Task, error) func google.golang.org/genproto/googleapis/cloud/tasks/v2.CloudTasksServer.DeleteQueue(Context, *tasks.DeleteQueueRequest) (*emptypb.Empty, error) func google.golang.org/genproto/googleapis/cloud/tasks/v2.CloudTasksServer.DeleteTask(Context, *tasks.DeleteTaskRequest) (*emptypb.Empty, error) func google.golang.org/genproto/googleapis/cloud/tasks/v2.CloudTasksServer.GetIamPolicy(Context, *v1.GetIamPolicyRequest) (*v1.Policy, error) func google.golang.org/genproto/googleapis/cloud/tasks/v2.CloudTasksServer.GetQueue(Context, *tasks.GetQueueRequest) (*tasks.Queue, error) func google.golang.org/genproto/googleapis/cloud/tasks/v2.CloudTasksServer.GetTask(Context, *tasks.GetTaskRequest) (*tasks.Task, error) func google.golang.org/genproto/googleapis/cloud/tasks/v2.CloudTasksServer.ListQueues(Context, *tasks.ListQueuesRequest) (*tasks.ListQueuesResponse, error) func google.golang.org/genproto/googleapis/cloud/tasks/v2.CloudTasksServer.ListTasks(Context, *tasks.ListTasksRequest) (*tasks.ListTasksResponse, error) func google.golang.org/genproto/googleapis/cloud/tasks/v2.CloudTasksServer.PauseQueue(Context, *tasks.PauseQueueRequest) (*tasks.Queue, error) func google.golang.org/genproto/googleapis/cloud/tasks/v2.CloudTasksServer.PurgeQueue(Context, *tasks.PurgeQueueRequest) (*tasks.Queue, error) func google.golang.org/genproto/googleapis/cloud/tasks/v2.CloudTasksServer.ResumeQueue(Context, *tasks.ResumeQueueRequest) (*tasks.Queue, error) func google.golang.org/genproto/googleapis/cloud/tasks/v2.CloudTasksServer.RunTask(Context, *tasks.RunTaskRequest) (*tasks.Task, error) func google.golang.org/genproto/googleapis/cloud/tasks/v2.CloudTasksServer.SetIamPolicy(Context, *v1.SetIamPolicyRequest) (*v1.Policy, error) func google.golang.org/genproto/googleapis/cloud/tasks/v2.CloudTasksServer.TestIamPermissions(Context, *v1.TestIamPermissionsRequest) (*v1.TestIamPermissionsResponse, error) func google.golang.org/genproto/googleapis/cloud/tasks/v2.CloudTasksServer.UpdateQueue(Context, *tasks.UpdateQueueRequest) (*tasks.Queue, error) func google.golang.org/genproto/googleapis/cloud/tasks/v2.(*UnimplementedCloudTasksServer).CreateQueue(Context, *tasks.CreateQueueRequest) (*tasks.Queue, error) func google.golang.org/genproto/googleapis/cloud/tasks/v2.(*UnimplementedCloudTasksServer).CreateTask(Context, *tasks.CreateTaskRequest) (*tasks.Task, error) func google.golang.org/genproto/googleapis/cloud/tasks/v2.(*UnimplementedCloudTasksServer).DeleteQueue(Context, *tasks.DeleteQueueRequest) (*emptypb.Empty, error) func google.golang.org/genproto/googleapis/cloud/tasks/v2.(*UnimplementedCloudTasksServer).DeleteTask(Context, *tasks.DeleteTaskRequest) (*emptypb.Empty, error) func google.golang.org/genproto/googleapis/cloud/tasks/v2.(*UnimplementedCloudTasksServer).GetIamPolicy(Context, *v1.GetIamPolicyRequest) (*v1.Policy, error) func google.golang.org/genproto/googleapis/cloud/tasks/v2.(*UnimplementedCloudTasksServer).GetQueue(Context, *tasks.GetQueueRequest) (*tasks.Queue, error) func google.golang.org/genproto/googleapis/cloud/tasks/v2.(*UnimplementedCloudTasksServer).GetTask(Context, *tasks.GetTaskRequest) (*tasks.Task, error) func google.golang.org/genproto/googleapis/cloud/tasks/v2.(*UnimplementedCloudTasksServer).ListQueues(Context, *tasks.ListQueuesRequest) (*tasks.ListQueuesResponse, error) func google.golang.org/genproto/googleapis/cloud/tasks/v2.(*UnimplementedCloudTasksServer).ListTasks(Context, *tasks.ListTasksRequest) (*tasks.ListTasksResponse, error) func google.golang.org/genproto/googleapis/cloud/tasks/v2.(*UnimplementedCloudTasksServer).PauseQueue(Context, *tasks.PauseQueueRequest) (*tasks.Queue, error) func google.golang.org/genproto/googleapis/cloud/tasks/v2.(*UnimplementedCloudTasksServer).PurgeQueue(Context, *tasks.PurgeQueueRequest) (*tasks.Queue, error) func google.golang.org/genproto/googleapis/cloud/tasks/v2.(*UnimplementedCloudTasksServer).ResumeQueue(Context, *tasks.ResumeQueueRequest) (*tasks.Queue, error) func google.golang.org/genproto/googleapis/cloud/tasks/v2.(*UnimplementedCloudTasksServer).RunTask(Context, *tasks.RunTaskRequest) (*tasks.Task, error) func google.golang.org/genproto/googleapis/cloud/tasks/v2.(*UnimplementedCloudTasksServer).SetIamPolicy(Context, *v1.SetIamPolicyRequest) (*v1.Policy, error) func google.golang.org/genproto/googleapis/cloud/tasks/v2.(*UnimplementedCloudTasksServer).TestIamPermissions(Context, *v1.TestIamPermissionsRequest) (*v1.TestIamPermissionsResponse, error) func google.golang.org/genproto/googleapis/cloud/tasks/v2.(*UnimplementedCloudTasksServer).UpdateQueue(Context, *tasks.UpdateQueueRequest) (*tasks.Queue, error) func google.golang.org/genproto/googleapis/container/v1.ClusterManagerClient.CancelOperation(ctx Context, in *container.CancelOperationRequest, opts ...grpc.CallOption) (*emptypb.Empty, error) func google.golang.org/genproto/googleapis/container/v1.ClusterManagerClient.CompleteIPRotation(ctx Context, in *container.CompleteIPRotationRequest, opts ...grpc.CallOption) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.ClusterManagerClient.CreateCluster(ctx Context, in *container.CreateClusterRequest, opts ...grpc.CallOption) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.ClusterManagerClient.CreateNodePool(ctx Context, in *container.CreateNodePoolRequest, opts ...grpc.CallOption) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.ClusterManagerClient.DeleteCluster(ctx Context, in *container.DeleteClusterRequest, opts ...grpc.CallOption) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.ClusterManagerClient.DeleteNodePool(ctx Context, in *container.DeleteNodePoolRequest, opts ...grpc.CallOption) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.ClusterManagerClient.GetCluster(ctx Context, in *container.GetClusterRequest, opts ...grpc.CallOption) (*container.Cluster, error) func google.golang.org/genproto/googleapis/container/v1.ClusterManagerClient.GetNodePool(ctx Context, in *container.GetNodePoolRequest, opts ...grpc.CallOption) (*container.NodePool, error) func google.golang.org/genproto/googleapis/container/v1.ClusterManagerClient.GetOperation(ctx Context, in *container.GetOperationRequest, opts ...grpc.CallOption) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.ClusterManagerClient.GetServerConfig(ctx Context, in *container.GetServerConfigRequest, opts ...grpc.CallOption) (*container.ServerConfig, error) func google.golang.org/genproto/googleapis/container/v1.ClusterManagerClient.ListClusters(ctx Context, in *container.ListClustersRequest, opts ...grpc.CallOption) (*container.ListClustersResponse, error) func google.golang.org/genproto/googleapis/container/v1.ClusterManagerClient.ListNodePools(ctx Context, in *container.ListNodePoolsRequest, opts ...grpc.CallOption) (*container.ListNodePoolsResponse, error) func google.golang.org/genproto/googleapis/container/v1.ClusterManagerClient.ListOperations(ctx Context, in *container.ListOperationsRequest, opts ...grpc.CallOption) (*container.ListOperationsResponse, error) func google.golang.org/genproto/googleapis/container/v1.ClusterManagerClient.ListUsableSubnetworks(ctx Context, in *container.ListUsableSubnetworksRequest, opts ...grpc.CallOption) (*container.ListUsableSubnetworksResponse, error) func google.golang.org/genproto/googleapis/container/v1.ClusterManagerClient.RollbackNodePoolUpgrade(ctx Context, in *container.RollbackNodePoolUpgradeRequest, opts ...grpc.CallOption) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.ClusterManagerClient.SetAddonsConfig(ctx Context, in *container.SetAddonsConfigRequest, opts ...grpc.CallOption) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.ClusterManagerClient.SetLabels(ctx Context, in *container.SetLabelsRequest, opts ...grpc.CallOption) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.ClusterManagerClient.SetLegacyAbac(ctx Context, in *container.SetLegacyAbacRequest, opts ...grpc.CallOption) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.ClusterManagerClient.SetLocations(ctx Context, in *container.SetLocationsRequest, opts ...grpc.CallOption) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.ClusterManagerClient.SetLoggingService(ctx Context, in *container.SetLoggingServiceRequest, opts ...grpc.CallOption) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.ClusterManagerClient.SetMaintenancePolicy(ctx Context, in *container.SetMaintenancePolicyRequest, opts ...grpc.CallOption) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.ClusterManagerClient.SetMasterAuth(ctx Context, in *container.SetMasterAuthRequest, opts ...grpc.CallOption) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.ClusterManagerClient.SetMonitoringService(ctx Context, in *container.SetMonitoringServiceRequest, opts ...grpc.CallOption) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.ClusterManagerClient.SetNetworkPolicy(ctx Context, in *container.SetNetworkPolicyRequest, opts ...grpc.CallOption) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.ClusterManagerClient.SetNodePoolAutoscaling(ctx Context, in *container.SetNodePoolAutoscalingRequest, opts ...grpc.CallOption) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.ClusterManagerClient.SetNodePoolManagement(ctx Context, in *container.SetNodePoolManagementRequest, opts ...grpc.CallOption) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.ClusterManagerClient.SetNodePoolSize(ctx Context, in *container.SetNodePoolSizeRequest, opts ...grpc.CallOption) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.ClusterManagerClient.StartIPRotation(ctx Context, in *container.StartIPRotationRequest, opts ...grpc.CallOption) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.ClusterManagerClient.UpdateCluster(ctx Context, in *container.UpdateClusterRequest, opts ...grpc.CallOption) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.ClusterManagerClient.UpdateMaster(ctx Context, in *container.UpdateMasterRequest, opts ...grpc.CallOption) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.ClusterManagerClient.UpdateNodePool(ctx Context, in *container.UpdateNodePoolRequest, opts ...grpc.CallOption) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.ClusterManagerServer.CancelOperation(Context, *container.CancelOperationRequest) (*emptypb.Empty, error) func google.golang.org/genproto/googleapis/container/v1.ClusterManagerServer.CompleteIPRotation(Context, *container.CompleteIPRotationRequest) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.ClusterManagerServer.CreateCluster(Context, *container.CreateClusterRequest) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.ClusterManagerServer.CreateNodePool(Context, *container.CreateNodePoolRequest) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.ClusterManagerServer.DeleteCluster(Context, *container.DeleteClusterRequest) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.ClusterManagerServer.DeleteNodePool(Context, *container.DeleteNodePoolRequest) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.ClusterManagerServer.GetCluster(Context, *container.GetClusterRequest) (*container.Cluster, error) func google.golang.org/genproto/googleapis/container/v1.ClusterManagerServer.GetNodePool(Context, *container.GetNodePoolRequest) (*container.NodePool, error) func google.golang.org/genproto/googleapis/container/v1.ClusterManagerServer.GetOperation(Context, *container.GetOperationRequest) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.ClusterManagerServer.GetServerConfig(Context, *container.GetServerConfigRequest) (*container.ServerConfig, error) func google.golang.org/genproto/googleapis/container/v1.ClusterManagerServer.ListClusters(Context, *container.ListClustersRequest) (*container.ListClustersResponse, error) func google.golang.org/genproto/googleapis/container/v1.ClusterManagerServer.ListNodePools(Context, *container.ListNodePoolsRequest) (*container.ListNodePoolsResponse, error) func google.golang.org/genproto/googleapis/container/v1.ClusterManagerServer.ListOperations(Context, *container.ListOperationsRequest) (*container.ListOperationsResponse, error) func google.golang.org/genproto/googleapis/container/v1.ClusterManagerServer.ListUsableSubnetworks(Context, *container.ListUsableSubnetworksRequest) (*container.ListUsableSubnetworksResponse, error) func google.golang.org/genproto/googleapis/container/v1.ClusterManagerServer.RollbackNodePoolUpgrade(Context, *container.RollbackNodePoolUpgradeRequest) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.ClusterManagerServer.SetAddonsConfig(Context, *container.SetAddonsConfigRequest) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.ClusterManagerServer.SetLabels(Context, *container.SetLabelsRequest) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.ClusterManagerServer.SetLegacyAbac(Context, *container.SetLegacyAbacRequest) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.ClusterManagerServer.SetLocations(Context, *container.SetLocationsRequest) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.ClusterManagerServer.SetLoggingService(Context, *container.SetLoggingServiceRequest) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.ClusterManagerServer.SetMaintenancePolicy(Context, *container.SetMaintenancePolicyRequest) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.ClusterManagerServer.SetMasterAuth(Context, *container.SetMasterAuthRequest) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.ClusterManagerServer.SetMonitoringService(Context, *container.SetMonitoringServiceRequest) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.ClusterManagerServer.SetNetworkPolicy(Context, *container.SetNetworkPolicyRequest) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.ClusterManagerServer.SetNodePoolAutoscaling(Context, *container.SetNodePoolAutoscalingRequest) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.ClusterManagerServer.SetNodePoolManagement(Context, *container.SetNodePoolManagementRequest) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.ClusterManagerServer.SetNodePoolSize(Context, *container.SetNodePoolSizeRequest) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.ClusterManagerServer.StartIPRotation(Context, *container.StartIPRotationRequest) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.ClusterManagerServer.UpdateCluster(Context, *container.UpdateClusterRequest) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.ClusterManagerServer.UpdateMaster(Context, *container.UpdateMasterRequest) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.ClusterManagerServer.UpdateNodePool(Context, *container.UpdateNodePoolRequest) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.(*UnimplementedClusterManagerServer).CancelOperation(Context, *container.CancelOperationRequest) (*emptypb.Empty, error) func google.golang.org/genproto/googleapis/container/v1.(*UnimplementedClusterManagerServer).CompleteIPRotation(Context, *container.CompleteIPRotationRequest) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.(*UnimplementedClusterManagerServer).CreateCluster(Context, *container.CreateClusterRequest) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.(*UnimplementedClusterManagerServer).CreateNodePool(Context, *container.CreateNodePoolRequest) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.(*UnimplementedClusterManagerServer).DeleteCluster(Context, *container.DeleteClusterRequest) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.(*UnimplementedClusterManagerServer).DeleteNodePool(Context, *container.DeleteNodePoolRequest) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.(*UnimplementedClusterManagerServer).GetCluster(Context, *container.GetClusterRequest) (*container.Cluster, error) func google.golang.org/genproto/googleapis/container/v1.(*UnimplementedClusterManagerServer).GetNodePool(Context, *container.GetNodePoolRequest) (*container.NodePool, error) func google.golang.org/genproto/googleapis/container/v1.(*UnimplementedClusterManagerServer).GetOperation(Context, *container.GetOperationRequest) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.(*UnimplementedClusterManagerServer).GetServerConfig(Context, *container.GetServerConfigRequest) (*container.ServerConfig, error) func google.golang.org/genproto/googleapis/container/v1.(*UnimplementedClusterManagerServer).ListClusters(Context, *container.ListClustersRequest) (*container.ListClustersResponse, error) func google.golang.org/genproto/googleapis/container/v1.(*UnimplementedClusterManagerServer).ListNodePools(Context, *container.ListNodePoolsRequest) (*container.ListNodePoolsResponse, error) func google.golang.org/genproto/googleapis/container/v1.(*UnimplementedClusterManagerServer).ListOperations(Context, *container.ListOperationsRequest) (*container.ListOperationsResponse, error) func google.golang.org/genproto/googleapis/container/v1.(*UnimplementedClusterManagerServer).ListUsableSubnetworks(Context, *container.ListUsableSubnetworksRequest) (*container.ListUsableSubnetworksResponse, error) func google.golang.org/genproto/googleapis/container/v1.(*UnimplementedClusterManagerServer).RollbackNodePoolUpgrade(Context, *container.RollbackNodePoolUpgradeRequest) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.(*UnimplementedClusterManagerServer).SetAddonsConfig(Context, *container.SetAddonsConfigRequest) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.(*UnimplementedClusterManagerServer).SetLabels(Context, *container.SetLabelsRequest) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.(*UnimplementedClusterManagerServer).SetLegacyAbac(Context, *container.SetLegacyAbacRequest) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.(*UnimplementedClusterManagerServer).SetLocations(Context, *container.SetLocationsRequest) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.(*UnimplementedClusterManagerServer).SetLoggingService(Context, *container.SetLoggingServiceRequest) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.(*UnimplementedClusterManagerServer).SetMaintenancePolicy(Context, *container.SetMaintenancePolicyRequest) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.(*UnimplementedClusterManagerServer).SetMasterAuth(Context, *container.SetMasterAuthRequest) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.(*UnimplementedClusterManagerServer).SetMonitoringService(Context, *container.SetMonitoringServiceRequest) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.(*UnimplementedClusterManagerServer).SetNetworkPolicy(Context, *container.SetNetworkPolicyRequest) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.(*UnimplementedClusterManagerServer).SetNodePoolAutoscaling(Context, *container.SetNodePoolAutoscalingRequest) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.(*UnimplementedClusterManagerServer).SetNodePoolManagement(Context, *container.SetNodePoolManagementRequest) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.(*UnimplementedClusterManagerServer).SetNodePoolSize(Context, *container.SetNodePoolSizeRequest) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.(*UnimplementedClusterManagerServer).StartIPRotation(Context, *container.StartIPRotationRequest) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.(*UnimplementedClusterManagerServer).UpdateCluster(Context, *container.UpdateClusterRequest) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.(*UnimplementedClusterManagerServer).UpdateMaster(Context, *container.UpdateMasterRequest) (*container.Operation, error) func google.golang.org/genproto/googleapis/container/v1.(*UnimplementedClusterManagerServer).UpdateNodePool(Context, *container.UpdateNodePoolRequest) (*container.Operation, error) func google.golang.org/genproto/googleapis/devtools/clouderrorreporting/v1beta1.ErrorGroupServiceClient.GetGroup(ctx Context, in *clouderrorreporting.GetGroupRequest, opts ...grpc.CallOption) (*clouderrorreporting.ErrorGroup, error) func google.golang.org/genproto/googleapis/devtools/clouderrorreporting/v1beta1.ErrorGroupServiceClient.UpdateGroup(ctx Context, in *clouderrorreporting.UpdateGroupRequest, opts ...grpc.CallOption) (*clouderrorreporting.ErrorGroup, error) func google.golang.org/genproto/googleapis/devtools/clouderrorreporting/v1beta1.ErrorGroupServiceServer.GetGroup(Context, *clouderrorreporting.GetGroupRequest) (*clouderrorreporting.ErrorGroup, error) func google.golang.org/genproto/googleapis/devtools/clouderrorreporting/v1beta1.ErrorGroupServiceServer.UpdateGroup(Context, *clouderrorreporting.UpdateGroupRequest) (*clouderrorreporting.ErrorGroup, error) func google.golang.org/genproto/googleapis/devtools/clouderrorreporting/v1beta1.ErrorStatsServiceClient.DeleteEvents(ctx Context, in *clouderrorreporting.DeleteEventsRequest, opts ...grpc.CallOption) (*clouderrorreporting.DeleteEventsResponse, error) func google.golang.org/genproto/googleapis/devtools/clouderrorreporting/v1beta1.ErrorStatsServiceClient.ListEvents(ctx Context, in *clouderrorreporting.ListEventsRequest, opts ...grpc.CallOption) (*clouderrorreporting.ListEventsResponse, error) func google.golang.org/genproto/googleapis/devtools/clouderrorreporting/v1beta1.ErrorStatsServiceClient.ListGroupStats(ctx Context, in *clouderrorreporting.ListGroupStatsRequest, opts ...grpc.CallOption) (*clouderrorreporting.ListGroupStatsResponse, error) func google.golang.org/genproto/googleapis/devtools/clouderrorreporting/v1beta1.ErrorStatsServiceServer.DeleteEvents(Context, *clouderrorreporting.DeleteEventsRequest) (*clouderrorreporting.DeleteEventsResponse, error) func google.golang.org/genproto/googleapis/devtools/clouderrorreporting/v1beta1.ErrorStatsServiceServer.ListEvents(Context, *clouderrorreporting.ListEventsRequest) (*clouderrorreporting.ListEventsResponse, error) func google.golang.org/genproto/googleapis/devtools/clouderrorreporting/v1beta1.ErrorStatsServiceServer.ListGroupStats(Context, *clouderrorreporting.ListGroupStatsRequest) (*clouderrorreporting.ListGroupStatsResponse, error) func google.golang.org/genproto/googleapis/devtools/clouderrorreporting/v1beta1.ReportErrorsServiceClient.ReportErrorEvent(ctx Context, in *clouderrorreporting.ReportErrorEventRequest, opts ...grpc.CallOption) (*clouderrorreporting.ReportErrorEventResponse, error) func google.golang.org/genproto/googleapis/devtools/clouderrorreporting/v1beta1.ReportErrorsServiceServer.ReportErrorEvent(Context, *clouderrorreporting.ReportErrorEventRequest) (*clouderrorreporting.ReportErrorEventResponse, error) func google.golang.org/genproto/googleapis/devtools/clouderrorreporting/v1beta1.(*UnimplementedErrorGroupServiceServer).GetGroup(Context, *clouderrorreporting.GetGroupRequest) (*clouderrorreporting.ErrorGroup, error) func google.golang.org/genproto/googleapis/devtools/clouderrorreporting/v1beta1.(*UnimplementedErrorGroupServiceServer).UpdateGroup(Context, *clouderrorreporting.UpdateGroupRequest) (*clouderrorreporting.ErrorGroup, error) func google.golang.org/genproto/googleapis/devtools/clouderrorreporting/v1beta1.(*UnimplementedErrorStatsServiceServer).DeleteEvents(Context, *clouderrorreporting.DeleteEventsRequest) (*clouderrorreporting.DeleteEventsResponse, error) func google.golang.org/genproto/googleapis/devtools/clouderrorreporting/v1beta1.(*UnimplementedErrorStatsServiceServer).ListEvents(Context, *clouderrorreporting.ListEventsRequest) (*clouderrorreporting.ListEventsResponse, error) func google.golang.org/genproto/googleapis/devtools/clouderrorreporting/v1beta1.(*UnimplementedErrorStatsServiceServer).ListGroupStats(Context, *clouderrorreporting.ListGroupStatsRequest) (*clouderrorreporting.ListGroupStatsResponse, error) func google.golang.org/genproto/googleapis/devtools/clouderrorreporting/v1beta1.(*UnimplementedReportErrorsServiceServer).ReportErrorEvent(Context, *clouderrorreporting.ReportErrorEventRequest) (*clouderrorreporting.ReportErrorEventResponse, error) func google.golang.org/genproto/googleapis/devtools/cloudprofiler/v2.ProfilerServiceClient.CreateOfflineProfile(ctx Context, in *cloudprofiler.CreateOfflineProfileRequest, opts ...grpc.CallOption) (*cloudprofiler.Profile, error) func google.golang.org/genproto/googleapis/devtools/cloudprofiler/v2.ProfilerServiceClient.CreateProfile(ctx Context, in *cloudprofiler.CreateProfileRequest, opts ...grpc.CallOption) (*cloudprofiler.Profile, error) func google.golang.org/genproto/googleapis/devtools/cloudprofiler/v2.ProfilerServiceClient.UpdateProfile(ctx Context, in *cloudprofiler.UpdateProfileRequest, opts ...grpc.CallOption) (*cloudprofiler.Profile, error) func google.golang.org/genproto/googleapis/devtools/cloudprofiler/v2.ProfilerServiceServer.CreateOfflineProfile(Context, *cloudprofiler.CreateOfflineProfileRequest) (*cloudprofiler.Profile, error) func google.golang.org/genproto/googleapis/devtools/cloudprofiler/v2.ProfilerServiceServer.CreateProfile(Context, *cloudprofiler.CreateProfileRequest) (*cloudprofiler.Profile, error) func google.golang.org/genproto/googleapis/devtools/cloudprofiler/v2.ProfilerServiceServer.UpdateProfile(Context, *cloudprofiler.UpdateProfileRequest) (*cloudprofiler.Profile, error) func google.golang.org/genproto/googleapis/devtools/cloudprofiler/v2.(*UnimplementedProfilerServiceServer).CreateOfflineProfile(Context, *cloudprofiler.CreateOfflineProfileRequest) (*cloudprofiler.Profile, error) func google.golang.org/genproto/googleapis/devtools/cloudprofiler/v2.(*UnimplementedProfilerServiceServer).CreateProfile(Context, *cloudprofiler.CreateProfileRequest) (*cloudprofiler.Profile, error) func google.golang.org/genproto/googleapis/devtools/cloudprofiler/v2.(*UnimplementedProfilerServiceServer).UpdateProfile(Context, *cloudprofiler.UpdateProfileRequest) (*cloudprofiler.Profile, error) func google.golang.org/genproto/googleapis/devtools/cloudtrace/v2.TraceServiceClient.BatchWriteSpans(ctx Context, in *cloudtrace.BatchWriteSpansRequest, opts ...grpc.CallOption) (*emptypb.Empty, error) func google.golang.org/genproto/googleapis/devtools/cloudtrace/v2.TraceServiceClient.CreateSpan(ctx Context, in *cloudtrace.Span, opts ...grpc.CallOption) (*cloudtrace.Span, error) func google.golang.org/genproto/googleapis/devtools/cloudtrace/v2.TraceServiceServer.BatchWriteSpans(Context, *cloudtrace.BatchWriteSpansRequest) (*emptypb.Empty, error) func google.golang.org/genproto/googleapis/devtools/cloudtrace/v2.TraceServiceServer.CreateSpan(Context, *cloudtrace.Span) (*cloudtrace.Span, error) func google.golang.org/genproto/googleapis/devtools/cloudtrace/v2.(*UnimplementedTraceServiceServer).BatchWriteSpans(Context, *cloudtrace.BatchWriteSpansRequest) (*emptypb.Empty, error) func google.golang.org/genproto/googleapis/devtools/cloudtrace/v2.(*UnimplementedTraceServiceServer).CreateSpan(Context, *cloudtrace.Span) (*cloudtrace.Span, error) func google.golang.org/genproto/googleapis/iam/v1.IAMPolicyClient.GetIamPolicy(ctx Context, in *iam.GetIamPolicyRequest, opts ...grpc.CallOption) (*iam.Policy, error) func google.golang.org/genproto/googleapis/iam/v1.IAMPolicyClient.SetIamPolicy(ctx Context, in *iam.SetIamPolicyRequest, opts ...grpc.CallOption) (*iam.Policy, error) func google.golang.org/genproto/googleapis/iam/v1.IAMPolicyClient.TestIamPermissions(ctx Context, in *iam.TestIamPermissionsRequest, opts ...grpc.CallOption) (*iam.TestIamPermissionsResponse, error) func google.golang.org/genproto/googleapis/iam/v1.IAMPolicyServer.GetIamPolicy(Context, *iam.GetIamPolicyRequest) (*iam.Policy, error) func google.golang.org/genproto/googleapis/iam/v1.IAMPolicyServer.SetIamPolicy(Context, *iam.SetIamPolicyRequest) (*iam.Policy, error) func google.golang.org/genproto/googleapis/iam/v1.IAMPolicyServer.TestIamPermissions(Context, *iam.TestIamPermissionsRequest) (*iam.TestIamPermissionsResponse, error) func google.golang.org/genproto/googleapis/iam/v1.(*UnimplementedIAMPolicyServer).GetIamPolicy(Context, *iam.GetIamPolicyRequest) (*iam.Policy, error) func google.golang.org/genproto/googleapis/iam/v1.(*UnimplementedIAMPolicyServer).SetIamPolicy(Context, *iam.SetIamPolicyRequest) (*iam.Policy, error) func google.golang.org/genproto/googleapis/iam/v1.(*UnimplementedIAMPolicyServer).TestIamPermissions(Context, *iam.TestIamPermissionsRequest) (*iam.TestIamPermissionsResponse, error) func google.golang.org/genproto/googleapis/logging/v2.ConfigServiceV2Client.CreateExclusion(ctx Context, in *logging.CreateExclusionRequest, opts ...grpc.CallOption) (*logging.LogExclusion, error) func google.golang.org/genproto/googleapis/logging/v2.ConfigServiceV2Client.CreateSink(ctx Context, in *logging.CreateSinkRequest, opts ...grpc.CallOption) (*logging.LogSink, error) func google.golang.org/genproto/googleapis/logging/v2.ConfigServiceV2Client.DeleteExclusion(ctx Context, in *logging.DeleteExclusionRequest, opts ...grpc.CallOption) (*emptypb.Empty, error) func google.golang.org/genproto/googleapis/logging/v2.ConfigServiceV2Client.DeleteSink(ctx Context, in *logging.DeleteSinkRequest, opts ...grpc.CallOption) (*emptypb.Empty, error) func google.golang.org/genproto/googleapis/logging/v2.ConfigServiceV2Client.GetBucket(ctx Context, in *logging.GetBucketRequest, opts ...grpc.CallOption) (*logging.LogBucket, error) func google.golang.org/genproto/googleapis/logging/v2.ConfigServiceV2Client.GetCmekSettings(ctx Context, in *logging.GetCmekSettingsRequest, opts ...grpc.CallOption) (*logging.CmekSettings, error) func google.golang.org/genproto/googleapis/logging/v2.ConfigServiceV2Client.GetExclusion(ctx Context, in *logging.GetExclusionRequest, opts ...grpc.CallOption) (*logging.LogExclusion, error) func google.golang.org/genproto/googleapis/logging/v2.ConfigServiceV2Client.GetSink(ctx Context, in *logging.GetSinkRequest, opts ...grpc.CallOption) (*logging.LogSink, error) func google.golang.org/genproto/googleapis/logging/v2.ConfigServiceV2Client.ListBuckets(ctx Context, in *logging.ListBucketsRequest, opts ...grpc.CallOption) (*logging.ListBucketsResponse, error) func google.golang.org/genproto/googleapis/logging/v2.ConfigServiceV2Client.ListExclusions(ctx Context, in *logging.ListExclusionsRequest, opts ...grpc.CallOption) (*logging.ListExclusionsResponse, error) func google.golang.org/genproto/googleapis/logging/v2.ConfigServiceV2Client.ListSinks(ctx Context, in *logging.ListSinksRequest, opts ...grpc.CallOption) (*logging.ListSinksResponse, error) func google.golang.org/genproto/googleapis/logging/v2.ConfigServiceV2Client.UpdateBucket(ctx Context, in *logging.UpdateBucketRequest, opts ...grpc.CallOption) (*logging.LogBucket, error) func google.golang.org/genproto/googleapis/logging/v2.ConfigServiceV2Client.UpdateCmekSettings(ctx Context, in *logging.UpdateCmekSettingsRequest, opts ...grpc.CallOption) (*logging.CmekSettings, error) func google.golang.org/genproto/googleapis/logging/v2.ConfigServiceV2Client.UpdateExclusion(ctx Context, in *logging.UpdateExclusionRequest, opts ...grpc.CallOption) (*logging.LogExclusion, error) func google.golang.org/genproto/googleapis/logging/v2.ConfigServiceV2Client.UpdateSink(ctx Context, in *logging.UpdateSinkRequest, opts ...grpc.CallOption) (*logging.LogSink, error) func google.golang.org/genproto/googleapis/logging/v2.ConfigServiceV2Server.CreateExclusion(Context, *logging.CreateExclusionRequest) (*logging.LogExclusion, error) func google.golang.org/genproto/googleapis/logging/v2.ConfigServiceV2Server.CreateSink(Context, *logging.CreateSinkRequest) (*logging.LogSink, error) func google.golang.org/genproto/googleapis/logging/v2.ConfigServiceV2Server.DeleteExclusion(Context, *logging.DeleteExclusionRequest) (*emptypb.Empty, error) func google.golang.org/genproto/googleapis/logging/v2.ConfigServiceV2Server.DeleteSink(Context, *logging.DeleteSinkRequest) (*emptypb.Empty, error) func google.golang.org/genproto/googleapis/logging/v2.ConfigServiceV2Server.GetBucket(Context, *logging.GetBucketRequest) (*logging.LogBucket, error) func google.golang.org/genproto/googleapis/logging/v2.ConfigServiceV2Server.GetCmekSettings(Context, *logging.GetCmekSettingsRequest) (*logging.CmekSettings, error) func google.golang.org/genproto/googleapis/logging/v2.ConfigServiceV2Server.GetExclusion(Context, *logging.GetExclusionRequest) (*logging.LogExclusion, error) func google.golang.org/genproto/googleapis/logging/v2.ConfigServiceV2Server.GetSink(Context, *logging.GetSinkRequest) (*logging.LogSink, error) func google.golang.org/genproto/googleapis/logging/v2.ConfigServiceV2Server.ListBuckets(Context, *logging.ListBucketsRequest) (*logging.ListBucketsResponse, error) func google.golang.org/genproto/googleapis/logging/v2.ConfigServiceV2Server.ListExclusions(Context, *logging.ListExclusionsRequest) (*logging.ListExclusionsResponse, error) func google.golang.org/genproto/googleapis/logging/v2.ConfigServiceV2Server.ListSinks(Context, *logging.ListSinksRequest) (*logging.ListSinksResponse, error) func google.golang.org/genproto/googleapis/logging/v2.ConfigServiceV2Server.UpdateBucket(Context, *logging.UpdateBucketRequest) (*logging.LogBucket, error) func google.golang.org/genproto/googleapis/logging/v2.ConfigServiceV2Server.UpdateCmekSettings(Context, *logging.UpdateCmekSettingsRequest) (*logging.CmekSettings, error) func google.golang.org/genproto/googleapis/logging/v2.ConfigServiceV2Server.UpdateExclusion(Context, *logging.UpdateExclusionRequest) (*logging.LogExclusion, error) func google.golang.org/genproto/googleapis/logging/v2.ConfigServiceV2Server.UpdateSink(Context, *logging.UpdateSinkRequest) (*logging.LogSink, error) func google.golang.org/genproto/googleapis/logging/v2.LoggingServiceV2Client.DeleteLog(ctx Context, in *logging.DeleteLogRequest, opts ...grpc.CallOption) (*emptypb.Empty, error) func google.golang.org/genproto/googleapis/logging/v2.LoggingServiceV2Client.ListLogEntries(ctx Context, in *logging.ListLogEntriesRequest, opts ...grpc.CallOption) (*logging.ListLogEntriesResponse, error) func google.golang.org/genproto/googleapis/logging/v2.LoggingServiceV2Client.ListLogs(ctx Context, in *logging.ListLogsRequest, opts ...grpc.CallOption) (*logging.ListLogsResponse, error) func google.golang.org/genproto/googleapis/logging/v2.LoggingServiceV2Client.ListMonitoredResourceDescriptors(ctx Context, in *logging.ListMonitoredResourceDescriptorsRequest, opts ...grpc.CallOption) (*logging.ListMonitoredResourceDescriptorsResponse, error) func google.golang.org/genproto/googleapis/logging/v2.LoggingServiceV2Client.WriteLogEntries(ctx Context, in *logging.WriteLogEntriesRequest, opts ...grpc.CallOption) (*logging.WriteLogEntriesResponse, error) func google.golang.org/genproto/googleapis/logging/v2.LoggingServiceV2Server.DeleteLog(Context, *logging.DeleteLogRequest) (*emptypb.Empty, error) func google.golang.org/genproto/googleapis/logging/v2.LoggingServiceV2Server.ListLogEntries(Context, *logging.ListLogEntriesRequest) (*logging.ListLogEntriesResponse, error) func google.golang.org/genproto/googleapis/logging/v2.LoggingServiceV2Server.ListLogs(Context, *logging.ListLogsRequest) (*logging.ListLogsResponse, error) func google.golang.org/genproto/googleapis/logging/v2.LoggingServiceV2Server.ListMonitoredResourceDescriptors(Context, *logging.ListMonitoredResourceDescriptorsRequest) (*logging.ListMonitoredResourceDescriptorsResponse, error) func google.golang.org/genproto/googleapis/logging/v2.LoggingServiceV2Server.WriteLogEntries(Context, *logging.WriteLogEntriesRequest) (*logging.WriteLogEntriesResponse, error) func google.golang.org/genproto/googleapis/logging/v2.MetricsServiceV2Client.CreateLogMetric(ctx Context, in *logging.CreateLogMetricRequest, opts ...grpc.CallOption) (*logging.LogMetric, error) func google.golang.org/genproto/googleapis/logging/v2.MetricsServiceV2Client.DeleteLogMetric(ctx Context, in *logging.DeleteLogMetricRequest, opts ...grpc.CallOption) (*emptypb.Empty, error) func google.golang.org/genproto/googleapis/logging/v2.MetricsServiceV2Client.GetLogMetric(ctx Context, in *logging.GetLogMetricRequest, opts ...grpc.CallOption) (*logging.LogMetric, error) func google.golang.org/genproto/googleapis/logging/v2.MetricsServiceV2Client.ListLogMetrics(ctx Context, in *logging.ListLogMetricsRequest, opts ...grpc.CallOption) (*logging.ListLogMetricsResponse, error) func google.golang.org/genproto/googleapis/logging/v2.MetricsServiceV2Client.UpdateLogMetric(ctx Context, in *logging.UpdateLogMetricRequest, opts ...grpc.CallOption) (*logging.LogMetric, error) func google.golang.org/genproto/googleapis/logging/v2.MetricsServiceV2Server.CreateLogMetric(Context, *logging.CreateLogMetricRequest) (*logging.LogMetric, error) func google.golang.org/genproto/googleapis/logging/v2.MetricsServiceV2Server.DeleteLogMetric(Context, *logging.DeleteLogMetricRequest) (*emptypb.Empty, error) func google.golang.org/genproto/googleapis/logging/v2.MetricsServiceV2Server.GetLogMetric(Context, *logging.GetLogMetricRequest) (*logging.LogMetric, error) func google.golang.org/genproto/googleapis/logging/v2.MetricsServiceV2Server.ListLogMetrics(Context, *logging.ListLogMetricsRequest) (*logging.ListLogMetricsResponse, error) func google.golang.org/genproto/googleapis/logging/v2.MetricsServiceV2Server.UpdateLogMetric(Context, *logging.UpdateLogMetricRequest) (*logging.LogMetric, error) func google.golang.org/genproto/googleapis/logging/v2.(*UnimplementedConfigServiceV2Server).CreateExclusion(Context, *logging.CreateExclusionRequest) (*logging.LogExclusion, error) func google.golang.org/genproto/googleapis/logging/v2.(*UnimplementedConfigServiceV2Server).CreateSink(Context, *logging.CreateSinkRequest) (*logging.LogSink, error) func google.golang.org/genproto/googleapis/logging/v2.(*UnimplementedConfigServiceV2Server).DeleteExclusion(Context, *logging.DeleteExclusionRequest) (*emptypb.Empty, error) func google.golang.org/genproto/googleapis/logging/v2.(*UnimplementedConfigServiceV2Server).DeleteSink(Context, *logging.DeleteSinkRequest) (*emptypb.Empty, error) func google.golang.org/genproto/googleapis/logging/v2.(*UnimplementedConfigServiceV2Server).GetBucket(Context, *logging.GetBucketRequest) (*logging.LogBucket, error) func google.golang.org/genproto/googleapis/logging/v2.(*UnimplementedConfigServiceV2Server).GetCmekSettings(Context, *logging.GetCmekSettingsRequest) (*logging.CmekSettings, error) func google.golang.org/genproto/googleapis/logging/v2.(*UnimplementedConfigServiceV2Server).GetExclusion(Context, *logging.GetExclusionRequest) (*logging.LogExclusion, error) func google.golang.org/genproto/googleapis/logging/v2.(*UnimplementedConfigServiceV2Server).GetSink(Context, *logging.GetSinkRequest) (*logging.LogSink, error) func google.golang.org/genproto/googleapis/logging/v2.(*UnimplementedConfigServiceV2Server).ListBuckets(Context, *logging.ListBucketsRequest) (*logging.ListBucketsResponse, error) func google.golang.org/genproto/googleapis/logging/v2.(*UnimplementedConfigServiceV2Server).ListExclusions(Context, *logging.ListExclusionsRequest) (*logging.ListExclusionsResponse, error) func google.golang.org/genproto/googleapis/logging/v2.(*UnimplementedConfigServiceV2Server).ListSinks(Context, *logging.ListSinksRequest) (*logging.ListSinksResponse, error) func google.golang.org/genproto/googleapis/logging/v2.(*UnimplementedConfigServiceV2Server).UpdateBucket(Context, *logging.UpdateBucketRequest) (*logging.LogBucket, error) func google.golang.org/genproto/googleapis/logging/v2.(*UnimplementedConfigServiceV2Server).UpdateCmekSettings(Context, *logging.UpdateCmekSettingsRequest) (*logging.CmekSettings, error) func google.golang.org/genproto/googleapis/logging/v2.(*UnimplementedConfigServiceV2Server).UpdateExclusion(Context, *logging.UpdateExclusionRequest) (*logging.LogExclusion, error) func google.golang.org/genproto/googleapis/logging/v2.(*UnimplementedConfigServiceV2Server).UpdateSink(Context, *logging.UpdateSinkRequest) (*logging.LogSink, error) func google.golang.org/genproto/googleapis/logging/v2.(*UnimplementedLoggingServiceV2Server).DeleteLog(Context, *logging.DeleteLogRequest) (*emptypb.Empty, error) func google.golang.org/genproto/googleapis/logging/v2.(*UnimplementedLoggingServiceV2Server).ListLogEntries(Context, *logging.ListLogEntriesRequest) (*logging.ListLogEntriesResponse, error) func google.golang.org/genproto/googleapis/logging/v2.(*UnimplementedLoggingServiceV2Server).ListLogs(Context, *logging.ListLogsRequest) (*logging.ListLogsResponse, error) func google.golang.org/genproto/googleapis/logging/v2.(*UnimplementedLoggingServiceV2Server).ListMonitoredResourceDescriptors(Context, *logging.ListMonitoredResourceDescriptorsRequest) (*logging.ListMonitoredResourceDescriptorsResponse, error) func google.golang.org/genproto/googleapis/logging/v2.(*UnimplementedLoggingServiceV2Server).WriteLogEntries(Context, *logging.WriteLogEntriesRequest) (*logging.WriteLogEntriesResponse, error) func google.golang.org/genproto/googleapis/logging/v2.(*UnimplementedMetricsServiceV2Server).CreateLogMetric(Context, *logging.CreateLogMetricRequest) (*logging.LogMetric, error) func google.golang.org/genproto/googleapis/logging/v2.(*UnimplementedMetricsServiceV2Server).DeleteLogMetric(Context, *logging.DeleteLogMetricRequest) (*emptypb.Empty, error) func google.golang.org/genproto/googleapis/logging/v2.(*UnimplementedMetricsServiceV2Server).GetLogMetric(Context, *logging.GetLogMetricRequest) (*logging.LogMetric, error) func google.golang.org/genproto/googleapis/logging/v2.(*UnimplementedMetricsServiceV2Server).ListLogMetrics(Context, *logging.ListLogMetricsRequest) (*logging.ListLogMetricsResponse, error) func google.golang.org/genproto/googleapis/logging/v2.(*UnimplementedMetricsServiceV2Server).UpdateLogMetric(Context, *logging.UpdateLogMetricRequest) (*logging.LogMetric, error) func google.golang.org/genproto/googleapis/monitoring/v3.AlertPolicyServiceClient.CreateAlertPolicy(ctx Context, in *monitoring.CreateAlertPolicyRequest, opts ...grpc.CallOption) (*monitoring.AlertPolicy, error) func google.golang.org/genproto/googleapis/monitoring/v3.AlertPolicyServiceClient.DeleteAlertPolicy(ctx Context, in *monitoring.DeleteAlertPolicyRequest, opts ...grpc.CallOption) (*emptypb.Empty, error) func google.golang.org/genproto/googleapis/monitoring/v3.AlertPolicyServiceClient.GetAlertPolicy(ctx Context, in *monitoring.GetAlertPolicyRequest, opts ...grpc.CallOption) (*monitoring.AlertPolicy, error) func google.golang.org/genproto/googleapis/monitoring/v3.AlertPolicyServiceClient.ListAlertPolicies(ctx Context, in *monitoring.ListAlertPoliciesRequest, opts ...grpc.CallOption) (*monitoring.ListAlertPoliciesResponse, error) func google.golang.org/genproto/googleapis/monitoring/v3.AlertPolicyServiceClient.UpdateAlertPolicy(ctx Context, in *monitoring.UpdateAlertPolicyRequest, opts ...grpc.CallOption) (*monitoring.AlertPolicy, error) func google.golang.org/genproto/googleapis/monitoring/v3.AlertPolicyServiceServer.CreateAlertPolicy(Context, *monitoring.CreateAlertPolicyRequest) (*monitoring.AlertPolicy, error) func google.golang.org/genproto/googleapis/monitoring/v3.AlertPolicyServiceServer.DeleteAlertPolicy(Context, *monitoring.DeleteAlertPolicyRequest) (*emptypb.Empty, error) func google.golang.org/genproto/googleapis/monitoring/v3.AlertPolicyServiceServer.GetAlertPolicy(Context, *monitoring.GetAlertPolicyRequest) (*monitoring.AlertPolicy, error) func google.golang.org/genproto/googleapis/monitoring/v3.AlertPolicyServiceServer.ListAlertPolicies(Context, *monitoring.ListAlertPoliciesRequest) (*monitoring.ListAlertPoliciesResponse, error) func google.golang.org/genproto/googleapis/monitoring/v3.AlertPolicyServiceServer.UpdateAlertPolicy(Context, *monitoring.UpdateAlertPolicyRequest) (*monitoring.AlertPolicy, error) func google.golang.org/genproto/googleapis/monitoring/v3.GroupServiceClient.CreateGroup(ctx Context, in *monitoring.CreateGroupRequest, opts ...grpc.CallOption) (*monitoring.Group, error) func google.golang.org/genproto/googleapis/monitoring/v3.GroupServiceClient.DeleteGroup(ctx Context, in *monitoring.DeleteGroupRequest, opts ...grpc.CallOption) (*emptypb.Empty, error) func google.golang.org/genproto/googleapis/monitoring/v3.GroupServiceClient.GetGroup(ctx Context, in *monitoring.GetGroupRequest, opts ...grpc.CallOption) (*monitoring.Group, error) func google.golang.org/genproto/googleapis/monitoring/v3.GroupServiceClient.ListGroupMembers(ctx Context, in *monitoring.ListGroupMembersRequest, opts ...grpc.CallOption) (*monitoring.ListGroupMembersResponse, error) func google.golang.org/genproto/googleapis/monitoring/v3.GroupServiceClient.ListGroups(ctx Context, in *monitoring.ListGroupsRequest, opts ...grpc.CallOption) (*monitoring.ListGroupsResponse, error) func google.golang.org/genproto/googleapis/monitoring/v3.GroupServiceClient.UpdateGroup(ctx Context, in *monitoring.UpdateGroupRequest, opts ...grpc.CallOption) (*monitoring.Group, error) func google.golang.org/genproto/googleapis/monitoring/v3.GroupServiceServer.CreateGroup(Context, *monitoring.CreateGroupRequest) (*monitoring.Group, error) func google.golang.org/genproto/googleapis/monitoring/v3.GroupServiceServer.DeleteGroup(Context, *monitoring.DeleteGroupRequest) (*emptypb.Empty, error) func google.golang.org/genproto/googleapis/monitoring/v3.GroupServiceServer.GetGroup(Context, *monitoring.GetGroupRequest) (*monitoring.Group, error) func google.golang.org/genproto/googleapis/monitoring/v3.GroupServiceServer.ListGroupMembers(Context, *monitoring.ListGroupMembersRequest) (*monitoring.ListGroupMembersResponse, error) func google.golang.org/genproto/googleapis/monitoring/v3.GroupServiceServer.ListGroups(Context, *monitoring.ListGroupsRequest) (*monitoring.ListGroupsResponse, error) func google.golang.org/genproto/googleapis/monitoring/v3.GroupServiceServer.UpdateGroup(Context, *monitoring.UpdateGroupRequest) (*monitoring.Group, error) func google.golang.org/genproto/googleapis/monitoring/v3.MetricServiceClient.CreateMetricDescriptor(ctx Context, in *monitoring.CreateMetricDescriptorRequest, opts ...grpc.CallOption) (*metric.MetricDescriptor, error) func google.golang.org/genproto/googleapis/monitoring/v3.MetricServiceClient.CreateTimeSeries(ctx Context, in *monitoring.CreateTimeSeriesRequest, opts ...grpc.CallOption) (*emptypb.Empty, error) func google.golang.org/genproto/googleapis/monitoring/v3.MetricServiceClient.DeleteMetricDescriptor(ctx Context, in *monitoring.DeleteMetricDescriptorRequest, opts ...grpc.CallOption) (*emptypb.Empty, error) func google.golang.org/genproto/googleapis/monitoring/v3.MetricServiceClient.GetMetricDescriptor(ctx Context, in *monitoring.GetMetricDescriptorRequest, opts ...grpc.CallOption) (*metric.MetricDescriptor, error) func google.golang.org/genproto/googleapis/monitoring/v3.MetricServiceClient.GetMonitoredResourceDescriptor(ctx Context, in *monitoring.GetMonitoredResourceDescriptorRequest, opts ...grpc.CallOption) (*monitoredres.MonitoredResourceDescriptor, error) func google.golang.org/genproto/googleapis/monitoring/v3.MetricServiceClient.ListMetricDescriptors(ctx Context, in *monitoring.ListMetricDescriptorsRequest, opts ...grpc.CallOption) (*monitoring.ListMetricDescriptorsResponse, error) func google.golang.org/genproto/googleapis/monitoring/v3.MetricServiceClient.ListMonitoredResourceDescriptors(ctx Context, in *monitoring.ListMonitoredResourceDescriptorsRequest, opts ...grpc.CallOption) (*monitoring.ListMonitoredResourceDescriptorsResponse, error) func google.golang.org/genproto/googleapis/monitoring/v3.MetricServiceClient.ListTimeSeries(ctx Context, in *monitoring.ListTimeSeriesRequest, opts ...grpc.CallOption) (*monitoring.ListTimeSeriesResponse, error) func google.golang.org/genproto/googleapis/monitoring/v3.MetricServiceServer.CreateMetricDescriptor(Context, *monitoring.CreateMetricDescriptorRequest) (*metric.MetricDescriptor, error) func google.golang.org/genproto/googleapis/monitoring/v3.MetricServiceServer.CreateTimeSeries(Context, *monitoring.CreateTimeSeriesRequest) (*emptypb.Empty, error) func google.golang.org/genproto/googleapis/monitoring/v3.MetricServiceServer.DeleteMetricDescriptor(Context, *monitoring.DeleteMetricDescriptorRequest) (*emptypb.Empty, error) func google.golang.org/genproto/googleapis/monitoring/v3.MetricServiceServer.GetMetricDescriptor(Context, *monitoring.GetMetricDescriptorRequest) (*metric.MetricDescriptor, error) func google.golang.org/genproto/googleapis/monitoring/v3.MetricServiceServer.GetMonitoredResourceDescriptor(Context, *monitoring.GetMonitoredResourceDescriptorRequest) (*monitoredres.MonitoredResourceDescriptor, error) func google.golang.org/genproto/googleapis/monitoring/v3.MetricServiceServer.ListMetricDescriptors(Context, *monitoring.ListMetricDescriptorsRequest) (*monitoring.ListMetricDescriptorsResponse, error) func google.golang.org/genproto/googleapis/monitoring/v3.MetricServiceServer.ListMonitoredResourceDescriptors(Context, *monitoring.ListMonitoredResourceDescriptorsRequest) (*monitoring.ListMonitoredResourceDescriptorsResponse, error) func google.golang.org/genproto/googleapis/monitoring/v3.MetricServiceServer.ListTimeSeries(Context, *monitoring.ListTimeSeriesRequest) (*monitoring.ListTimeSeriesResponse, error) func google.golang.org/genproto/googleapis/monitoring/v3.NotificationChannelServiceClient.CreateNotificationChannel(ctx Context, in *monitoring.CreateNotificationChannelRequest, opts ...grpc.CallOption) (*monitoring.NotificationChannel, error) func google.golang.org/genproto/googleapis/monitoring/v3.NotificationChannelServiceClient.DeleteNotificationChannel(ctx Context, in *monitoring.DeleteNotificationChannelRequest, opts ...grpc.CallOption) (*emptypb.Empty, error) func google.golang.org/genproto/googleapis/monitoring/v3.NotificationChannelServiceClient.GetNotificationChannel(ctx Context, in *monitoring.GetNotificationChannelRequest, opts ...grpc.CallOption) (*monitoring.NotificationChannel, error) func google.golang.org/genproto/googleapis/monitoring/v3.NotificationChannelServiceClient.GetNotificationChannelDescriptor(ctx Context, in *monitoring.GetNotificationChannelDescriptorRequest, opts ...grpc.CallOption) (*monitoring.NotificationChannelDescriptor, error) func google.golang.org/genproto/googleapis/monitoring/v3.NotificationChannelServiceClient.GetNotificationChannelVerificationCode(ctx Context, in *monitoring.GetNotificationChannelVerificationCodeRequest, opts ...grpc.CallOption) (*monitoring.GetNotificationChannelVerificationCodeResponse, error) func google.golang.org/genproto/googleapis/monitoring/v3.NotificationChannelServiceClient.ListNotificationChannelDescriptors(ctx Context, in *monitoring.ListNotificationChannelDescriptorsRequest, opts ...grpc.CallOption) (*monitoring.ListNotificationChannelDescriptorsResponse, error) func google.golang.org/genproto/googleapis/monitoring/v3.NotificationChannelServiceClient.ListNotificationChannels(ctx Context, in *monitoring.ListNotificationChannelsRequest, opts ...grpc.CallOption) (*monitoring.ListNotificationChannelsResponse, error) func google.golang.org/genproto/googleapis/monitoring/v3.NotificationChannelServiceClient.SendNotificationChannelVerificationCode(ctx Context, in *monitoring.SendNotificationChannelVerificationCodeRequest, opts ...grpc.CallOption) (*emptypb.Empty, error) func google.golang.org/genproto/googleapis/monitoring/v3.NotificationChannelServiceClient.UpdateNotificationChannel(ctx Context, in *monitoring.UpdateNotificationChannelRequest, opts ...grpc.CallOption) (*monitoring.NotificationChannel, error) func google.golang.org/genproto/googleapis/monitoring/v3.NotificationChannelServiceClient.VerifyNotificationChannel(ctx Context, in *monitoring.VerifyNotificationChannelRequest, opts ...grpc.CallOption) (*monitoring.NotificationChannel, error) func google.golang.org/genproto/googleapis/monitoring/v3.NotificationChannelServiceServer.CreateNotificationChannel(Context, *monitoring.CreateNotificationChannelRequest) (*monitoring.NotificationChannel, error) func google.golang.org/genproto/googleapis/monitoring/v3.NotificationChannelServiceServer.DeleteNotificationChannel(Context, *monitoring.DeleteNotificationChannelRequest) (*emptypb.Empty, error) func google.golang.org/genproto/googleapis/monitoring/v3.NotificationChannelServiceServer.GetNotificationChannel(Context, *monitoring.GetNotificationChannelRequest) (*monitoring.NotificationChannel, error) func google.golang.org/genproto/googleapis/monitoring/v3.NotificationChannelServiceServer.GetNotificationChannelDescriptor(Context, *monitoring.GetNotificationChannelDescriptorRequest) (*monitoring.NotificationChannelDescriptor, error) func google.golang.org/genproto/googleapis/monitoring/v3.NotificationChannelServiceServer.GetNotificationChannelVerificationCode(Context, *monitoring.GetNotificationChannelVerificationCodeRequest) (*monitoring.GetNotificationChannelVerificationCodeResponse, error) func google.golang.org/genproto/googleapis/monitoring/v3.NotificationChannelServiceServer.ListNotificationChannelDescriptors(Context, *monitoring.ListNotificationChannelDescriptorsRequest) (*monitoring.ListNotificationChannelDescriptorsResponse, error) func google.golang.org/genproto/googleapis/monitoring/v3.NotificationChannelServiceServer.ListNotificationChannels(Context, *monitoring.ListNotificationChannelsRequest) (*monitoring.ListNotificationChannelsResponse, error) func google.golang.org/genproto/googleapis/monitoring/v3.NotificationChannelServiceServer.SendNotificationChannelVerificationCode(Context, *monitoring.SendNotificationChannelVerificationCodeRequest) (*emptypb.Empty, error) func google.golang.org/genproto/googleapis/monitoring/v3.NotificationChannelServiceServer.UpdateNotificationChannel(Context, *monitoring.UpdateNotificationChannelRequest) (*monitoring.NotificationChannel, error) func google.golang.org/genproto/googleapis/monitoring/v3.NotificationChannelServiceServer.VerifyNotificationChannel(Context, *monitoring.VerifyNotificationChannelRequest) (*monitoring.NotificationChannel, error) func google.golang.org/genproto/googleapis/monitoring/v3.ServiceMonitoringServiceClient.CreateService(ctx Context, in *monitoring.CreateServiceRequest, opts ...grpc.CallOption) (*monitoring.Service, error) func google.golang.org/genproto/googleapis/monitoring/v3.ServiceMonitoringServiceClient.CreateServiceLevelObjective(ctx Context, in *monitoring.CreateServiceLevelObjectiveRequest, opts ...grpc.CallOption) (*monitoring.ServiceLevelObjective, error) func google.golang.org/genproto/googleapis/monitoring/v3.ServiceMonitoringServiceClient.DeleteService(ctx Context, in *monitoring.DeleteServiceRequest, opts ...grpc.CallOption) (*emptypb.Empty, error) func google.golang.org/genproto/googleapis/monitoring/v3.ServiceMonitoringServiceClient.DeleteServiceLevelObjective(ctx Context, in *monitoring.DeleteServiceLevelObjectiveRequest, opts ...grpc.CallOption) (*emptypb.Empty, error) func google.golang.org/genproto/googleapis/monitoring/v3.ServiceMonitoringServiceClient.GetService(ctx Context, in *monitoring.GetServiceRequest, opts ...grpc.CallOption) (*monitoring.Service, error) func google.golang.org/genproto/googleapis/monitoring/v3.ServiceMonitoringServiceClient.GetServiceLevelObjective(ctx Context, in *monitoring.GetServiceLevelObjectiveRequest, opts ...grpc.CallOption) (*monitoring.ServiceLevelObjective, error) func google.golang.org/genproto/googleapis/monitoring/v3.ServiceMonitoringServiceClient.ListServiceLevelObjectives(ctx Context, in *monitoring.ListServiceLevelObjectivesRequest, opts ...grpc.CallOption) (*monitoring.ListServiceLevelObjectivesResponse, error) func google.golang.org/genproto/googleapis/monitoring/v3.ServiceMonitoringServiceClient.ListServices(ctx Context, in *monitoring.ListServicesRequest, opts ...grpc.CallOption) (*monitoring.ListServicesResponse, error) func google.golang.org/genproto/googleapis/monitoring/v3.ServiceMonitoringServiceClient.UpdateService(ctx Context, in *monitoring.UpdateServiceRequest, opts ...grpc.CallOption) (*monitoring.Service, error) func google.golang.org/genproto/googleapis/monitoring/v3.ServiceMonitoringServiceClient.UpdateServiceLevelObjective(ctx Context, in *monitoring.UpdateServiceLevelObjectiveRequest, opts ...grpc.CallOption) (*monitoring.ServiceLevelObjective, error) func google.golang.org/genproto/googleapis/monitoring/v3.ServiceMonitoringServiceServer.CreateService(Context, *monitoring.CreateServiceRequest) (*monitoring.Service, error) func google.golang.org/genproto/googleapis/monitoring/v3.ServiceMonitoringServiceServer.CreateServiceLevelObjective(Context, *monitoring.CreateServiceLevelObjectiveRequest) (*monitoring.ServiceLevelObjective, error) func google.golang.org/genproto/googleapis/monitoring/v3.ServiceMonitoringServiceServer.DeleteService(Context, *monitoring.DeleteServiceRequest) (*emptypb.Empty, error) func google.golang.org/genproto/googleapis/monitoring/v3.ServiceMonitoringServiceServer.DeleteServiceLevelObjective(Context, *monitoring.DeleteServiceLevelObjectiveRequest) (*emptypb.Empty, error) func google.golang.org/genproto/googleapis/monitoring/v3.ServiceMonitoringServiceServer.GetService(Context, *monitoring.GetServiceRequest) (*monitoring.Service, error) func google.golang.org/genproto/googleapis/monitoring/v3.ServiceMonitoringServiceServer.GetServiceLevelObjective(Context, *monitoring.GetServiceLevelObjectiveRequest) (*monitoring.ServiceLevelObjective, error) func google.golang.org/genproto/googleapis/monitoring/v3.ServiceMonitoringServiceServer.ListServiceLevelObjectives(Context, *monitoring.ListServiceLevelObjectivesRequest) (*monitoring.ListServiceLevelObjectivesResponse, error) func google.golang.org/genproto/googleapis/monitoring/v3.ServiceMonitoringServiceServer.ListServices(Context, *monitoring.ListServicesRequest) (*monitoring.ListServicesResponse, error) func google.golang.org/genproto/googleapis/monitoring/v3.ServiceMonitoringServiceServer.UpdateService(Context, *monitoring.UpdateServiceRequest) (*monitoring.Service, error) func google.golang.org/genproto/googleapis/monitoring/v3.ServiceMonitoringServiceServer.UpdateServiceLevelObjective(Context, *monitoring.UpdateServiceLevelObjectiveRequest) (*monitoring.ServiceLevelObjective, error) func google.golang.org/genproto/googleapis/monitoring/v3.(*UnimplementedAlertPolicyServiceServer).CreateAlertPolicy(Context, *monitoring.CreateAlertPolicyRequest) (*monitoring.AlertPolicy, error) func google.golang.org/genproto/googleapis/monitoring/v3.(*UnimplementedAlertPolicyServiceServer).DeleteAlertPolicy(Context, *monitoring.DeleteAlertPolicyRequest) (*emptypb.Empty, error) func google.golang.org/genproto/googleapis/monitoring/v3.(*UnimplementedAlertPolicyServiceServer).GetAlertPolicy(Context, *monitoring.GetAlertPolicyRequest) (*monitoring.AlertPolicy, error) func google.golang.org/genproto/googleapis/monitoring/v3.(*UnimplementedAlertPolicyServiceServer).ListAlertPolicies(Context, *monitoring.ListAlertPoliciesRequest) (*monitoring.ListAlertPoliciesResponse, error) func google.golang.org/genproto/googleapis/monitoring/v3.(*UnimplementedAlertPolicyServiceServer).UpdateAlertPolicy(Context, *monitoring.UpdateAlertPolicyRequest) (*monitoring.AlertPolicy, error) func google.golang.org/genproto/googleapis/monitoring/v3.(*UnimplementedGroupServiceServer).CreateGroup(Context, *monitoring.CreateGroupRequest) (*monitoring.Group, error) func google.golang.org/genproto/googleapis/monitoring/v3.(*UnimplementedGroupServiceServer).DeleteGroup(Context, *monitoring.DeleteGroupRequest) (*emptypb.Empty, error) func google.golang.org/genproto/googleapis/monitoring/v3.(*UnimplementedGroupServiceServer).GetGroup(Context, *monitoring.GetGroupRequest) (*monitoring.Group, error) func google.golang.org/genproto/googleapis/monitoring/v3.(*UnimplementedGroupServiceServer).ListGroupMembers(Context, *monitoring.ListGroupMembersRequest) (*monitoring.ListGroupMembersResponse, error) func google.golang.org/genproto/googleapis/monitoring/v3.(*UnimplementedGroupServiceServer).ListGroups(Context, *monitoring.ListGroupsRequest) (*monitoring.ListGroupsResponse, error) func google.golang.org/genproto/googleapis/monitoring/v3.(*UnimplementedGroupServiceServer).UpdateGroup(Context, *monitoring.UpdateGroupRequest) (*monitoring.Group, error) func google.golang.org/genproto/googleapis/monitoring/v3.(*UnimplementedMetricServiceServer).CreateMetricDescriptor(Context, *monitoring.CreateMetricDescriptorRequest) (*metric.MetricDescriptor, error) func google.golang.org/genproto/googleapis/monitoring/v3.(*UnimplementedMetricServiceServer).CreateTimeSeries(Context, *monitoring.CreateTimeSeriesRequest) (*emptypb.Empty, error) func google.golang.org/genproto/googleapis/monitoring/v3.(*UnimplementedMetricServiceServer).DeleteMetricDescriptor(Context, *monitoring.DeleteMetricDescriptorRequest) (*emptypb.Empty, error) func google.golang.org/genproto/googleapis/monitoring/v3.(*UnimplementedMetricServiceServer).GetMetricDescriptor(Context, *monitoring.GetMetricDescriptorRequest) (*metric.MetricDescriptor, error) func google.golang.org/genproto/googleapis/monitoring/v3.(*UnimplementedMetricServiceServer).GetMonitoredResourceDescriptor(Context, *monitoring.GetMonitoredResourceDescriptorRequest) (*monitoredres.MonitoredResourceDescriptor, error) func google.golang.org/genproto/googleapis/monitoring/v3.(*UnimplementedMetricServiceServer).ListMetricDescriptors(Context, *monitoring.ListMetricDescriptorsRequest) (*monitoring.ListMetricDescriptorsResponse, error) func google.golang.org/genproto/googleapis/monitoring/v3.(*UnimplementedMetricServiceServer).ListMonitoredResourceDescriptors(Context, *monitoring.ListMonitoredResourceDescriptorsRequest) (*monitoring.ListMonitoredResourceDescriptorsResponse, error) func google.golang.org/genproto/googleapis/monitoring/v3.(*UnimplementedMetricServiceServer).ListTimeSeries(Context, *monitoring.ListTimeSeriesRequest) (*monitoring.ListTimeSeriesResponse, error) func google.golang.org/genproto/googleapis/monitoring/v3.(*UnimplementedNotificationChannelServiceServer).CreateNotificationChannel(Context, *monitoring.CreateNotificationChannelRequest) (*monitoring.NotificationChannel, error) func google.golang.org/genproto/googleapis/monitoring/v3.(*UnimplementedNotificationChannelServiceServer).DeleteNotificationChannel(Context, *monitoring.DeleteNotificationChannelRequest) (*emptypb.Empty, error) func google.golang.org/genproto/googleapis/monitoring/v3.(*UnimplementedNotificationChannelServiceServer).GetNotificationChannel(Context, *monitoring.GetNotificationChannelRequest) (*monitoring.NotificationChannel, error) func google.golang.org/genproto/googleapis/monitoring/v3.(*UnimplementedNotificationChannelServiceServer).GetNotificationChannelDescriptor(Context, *monitoring.GetNotificationChannelDescriptorRequest) (*monitoring.NotificationChannelDescriptor, error) func google.golang.org/genproto/googleapis/monitoring/v3.(*UnimplementedNotificationChannelServiceServer).GetNotificationChannelVerificationCode(Context, *monitoring.GetNotificationChannelVerificationCodeRequest) (*monitoring.GetNotificationChannelVerificationCodeResponse, error) func google.golang.org/genproto/googleapis/monitoring/v3.(*UnimplementedNotificationChannelServiceServer).ListNotificationChannelDescriptors(Context, *monitoring.ListNotificationChannelDescriptorsRequest) (*monitoring.ListNotificationChannelDescriptorsResponse, error) func google.golang.org/genproto/googleapis/monitoring/v3.(*UnimplementedNotificationChannelServiceServer).ListNotificationChannels(Context, *monitoring.ListNotificationChannelsRequest) (*monitoring.ListNotificationChannelsResponse, error) func google.golang.org/genproto/googleapis/monitoring/v3.(*UnimplementedNotificationChannelServiceServer).SendNotificationChannelVerificationCode(Context, *monitoring.SendNotificationChannelVerificationCodeRequest) (*emptypb.Empty, error) func google.golang.org/genproto/googleapis/monitoring/v3.(*UnimplementedNotificationChannelServiceServer).UpdateNotificationChannel(Context, *monitoring.UpdateNotificationChannelRequest) (*monitoring.NotificationChannel, error) func google.golang.org/genproto/googleapis/monitoring/v3.(*UnimplementedNotificationChannelServiceServer).VerifyNotificationChannel(Context, *monitoring.VerifyNotificationChannelRequest) (*monitoring.NotificationChannel, error) func google.golang.org/genproto/googleapis/monitoring/v3.(*UnimplementedServiceMonitoringServiceServer).CreateService(Context, *monitoring.CreateServiceRequest) (*monitoring.Service, error) func google.golang.org/genproto/googleapis/monitoring/v3.(*UnimplementedServiceMonitoringServiceServer).CreateServiceLevelObjective(Context, *monitoring.CreateServiceLevelObjectiveRequest) (*monitoring.ServiceLevelObjective, error) func google.golang.org/genproto/googleapis/monitoring/v3.(*UnimplementedServiceMonitoringServiceServer).DeleteService(Context, *monitoring.DeleteServiceRequest) (*emptypb.Empty, error) func google.golang.org/genproto/googleapis/monitoring/v3.(*UnimplementedServiceMonitoringServiceServer).DeleteServiceLevelObjective(Context, *monitoring.DeleteServiceLevelObjectiveRequest) (*emptypb.Empty, error) func google.golang.org/genproto/googleapis/monitoring/v3.(*UnimplementedServiceMonitoringServiceServer).GetService(Context, *monitoring.GetServiceRequest) (*monitoring.Service, error) func google.golang.org/genproto/googleapis/monitoring/v3.(*UnimplementedServiceMonitoringServiceServer).GetServiceLevelObjective(Context, *monitoring.GetServiceLevelObjectiveRequest) (*monitoring.ServiceLevelObjective, error) func google.golang.org/genproto/googleapis/monitoring/v3.(*UnimplementedServiceMonitoringServiceServer).ListServiceLevelObjectives(Context, *monitoring.ListServiceLevelObjectivesRequest) (*monitoring.ListServiceLevelObjectivesResponse, error) func google.golang.org/genproto/googleapis/monitoring/v3.(*UnimplementedServiceMonitoringServiceServer).ListServices(Context, *monitoring.ListServicesRequest) (*monitoring.ListServicesResponse, error) func google.golang.org/genproto/googleapis/monitoring/v3.(*UnimplementedServiceMonitoringServiceServer).UpdateService(Context, *monitoring.UpdateServiceRequest) (*monitoring.Service, error) func google.golang.org/genproto/googleapis/monitoring/v3.(*UnimplementedServiceMonitoringServiceServer).UpdateServiceLevelObjective(Context, *monitoring.UpdateServiceLevelObjectiveRequest) (*monitoring.ServiceLevelObjective, error) func google.golang.org/genproto/googleapis/monitoring/v3.(*UnimplementedUptimeCheckServiceServer).CreateUptimeCheckConfig(Context, *monitoring.CreateUptimeCheckConfigRequest) (*monitoring.UptimeCheckConfig, error) func google.golang.org/genproto/googleapis/monitoring/v3.(*UnimplementedUptimeCheckServiceServer).DeleteUptimeCheckConfig(Context, *monitoring.DeleteUptimeCheckConfigRequest) (*emptypb.Empty, error) func google.golang.org/genproto/googleapis/monitoring/v3.(*UnimplementedUptimeCheckServiceServer).GetUptimeCheckConfig(Context, *monitoring.GetUptimeCheckConfigRequest) (*monitoring.UptimeCheckConfig, error) func google.golang.org/genproto/googleapis/monitoring/v3.(*UnimplementedUptimeCheckServiceServer).ListUptimeCheckConfigs(Context, *monitoring.ListUptimeCheckConfigsRequest) (*monitoring.ListUptimeCheckConfigsResponse, error) func google.golang.org/genproto/googleapis/monitoring/v3.(*UnimplementedUptimeCheckServiceServer).ListUptimeCheckIps(Context, *monitoring.ListUptimeCheckIpsRequest) (*monitoring.ListUptimeCheckIpsResponse, error) func google.golang.org/genproto/googleapis/monitoring/v3.(*UnimplementedUptimeCheckServiceServer).UpdateUptimeCheckConfig(Context, *monitoring.UpdateUptimeCheckConfigRequest) (*monitoring.UptimeCheckConfig, error) func google.golang.org/genproto/googleapis/monitoring/v3.UptimeCheckServiceClient.CreateUptimeCheckConfig(ctx Context, in *monitoring.CreateUptimeCheckConfigRequest, opts ...grpc.CallOption) (*monitoring.UptimeCheckConfig, error) func google.golang.org/genproto/googleapis/monitoring/v3.UptimeCheckServiceClient.DeleteUptimeCheckConfig(ctx Context, in *monitoring.DeleteUptimeCheckConfigRequest, opts ...grpc.CallOption) (*emptypb.Empty, error) func google.golang.org/genproto/googleapis/monitoring/v3.UptimeCheckServiceClient.GetUptimeCheckConfig(ctx Context, in *monitoring.GetUptimeCheckConfigRequest, opts ...grpc.CallOption) (*monitoring.UptimeCheckConfig, error) func google.golang.org/genproto/googleapis/monitoring/v3.UptimeCheckServiceClient.ListUptimeCheckConfigs(ctx Context, in *monitoring.ListUptimeCheckConfigsRequest, opts ...grpc.CallOption) (*monitoring.ListUptimeCheckConfigsResponse, error) func google.golang.org/genproto/googleapis/monitoring/v3.UptimeCheckServiceClient.ListUptimeCheckIps(ctx Context, in *monitoring.ListUptimeCheckIpsRequest, opts ...grpc.CallOption) (*monitoring.ListUptimeCheckIpsResponse, error) func google.golang.org/genproto/googleapis/monitoring/v3.UptimeCheckServiceClient.UpdateUptimeCheckConfig(ctx Context, in *monitoring.UpdateUptimeCheckConfigRequest, opts ...grpc.CallOption) (*monitoring.UptimeCheckConfig, error) func google.golang.org/genproto/googleapis/monitoring/v3.UptimeCheckServiceServer.CreateUptimeCheckConfig(Context, *monitoring.CreateUptimeCheckConfigRequest) (*monitoring.UptimeCheckConfig, error) func google.golang.org/genproto/googleapis/monitoring/v3.UptimeCheckServiceServer.DeleteUptimeCheckConfig(Context, *monitoring.DeleteUptimeCheckConfigRequest) (*emptypb.Empty, error) func google.golang.org/genproto/googleapis/monitoring/v3.UptimeCheckServiceServer.GetUptimeCheckConfig(Context, *monitoring.GetUptimeCheckConfigRequest) (*monitoring.UptimeCheckConfig, error) func google.golang.org/genproto/googleapis/monitoring/v3.UptimeCheckServiceServer.ListUptimeCheckConfigs(Context, *monitoring.ListUptimeCheckConfigsRequest) (*monitoring.ListUptimeCheckConfigsResponse, error) func google.golang.org/genproto/googleapis/monitoring/v3.UptimeCheckServiceServer.ListUptimeCheckIps(Context, *monitoring.ListUptimeCheckIpsRequest) (*monitoring.ListUptimeCheckIpsResponse, error) func google.golang.org/genproto/googleapis/monitoring/v3.UptimeCheckServiceServer.UpdateUptimeCheckConfig(Context, *monitoring.UpdateUptimeCheckConfigRequest) (*monitoring.UptimeCheckConfig, error) func google.golang.org/grpc.DialContext(ctx Context, target string, opts ...grpc.DialOption) (conn *grpc.ClientConn, err error) func google.golang.org/grpc.Invoke(ctx Context, method string, args, reply interface{}, cc *grpc.ClientConn, opts ...grpc.CallOption) error func google.golang.org/grpc.Method(ctx Context) (string, bool) func google.golang.org/grpc.NewClientStream(ctx Context, desc *grpc.StreamDesc, cc *grpc.ClientConn, method string, opts ...grpc.CallOption) (grpc.ClientStream, error) func google.golang.org/grpc.NewContextWithServerTransportStream(ctx Context, stream grpc.ServerTransportStream) Context func google.golang.org/grpc.SendHeader(ctx Context, md metadata.MD) error func google.golang.org/grpc.ServerTransportStreamFromContext(ctx Context) grpc.ServerTransportStream func google.golang.org/grpc.SetHeader(ctx Context, md metadata.MD) error func google.golang.org/grpc.SetTrailer(ctx Context, md metadata.MD) error func google.golang.org/grpc.(*ClientConn).Invoke(ctx Context, method string, args, reply interface{}, opts ...grpc.CallOption) error func google.golang.org/grpc.(*ClientConn).NewStream(ctx Context, desc *grpc.StreamDesc, method string, opts ...grpc.CallOption) (grpc.ClientStream, error) func google.golang.org/grpc.(*ClientConn).WaitForStateChange(ctx Context, sourceState connectivity.State) bool func google.golang.org/grpc.ClientConnInterface.Invoke(ctx Context, method string, args interface{}, reply interface{}, opts ...grpc.CallOption) error func google.golang.org/grpc.ClientConnInterface.NewStream(ctx Context, desc *grpc.StreamDesc, method string, opts ...grpc.CallOption) (grpc.ClientStream, error) func google.golang.org/grpc/balancer/grpclb/grpc_lb_v1.LoadBalancerClient.BalanceLoad(ctx Context, opts ...grpc.CallOption) (grpc_lb_v1.LoadBalancer_BalanceLoadClient, error) func google.golang.org/grpc/connectivity.Reporter.WaitForStateChange(Context, connectivity.State) bool func google.golang.org/grpc/credentials.CheckSecurityLevel(ctx Context, level credentials.SecurityLevel) error func google.golang.org/grpc/credentials.ClientHandshakeInfoFromContext(ctx Context) credentials.ClientHandshakeInfo func google.golang.org/grpc/credentials.RequestInfoFromContext(ctx Context) (ri credentials.RequestInfo, ok bool) func google.golang.org/grpc/credentials.PerRPCCredentials.GetRequestMetadata(ctx Context, uri ...string) (map[string]string, error) func google.golang.org/grpc/credentials.TransportCredentials.ClientHandshake(Context, string, net.Conn) (net.Conn, credentials.AuthInfo, error) func google.golang.org/grpc/credentials/alts.AuthInfoFromContext(ctx Context) (alts.AuthInfo, error) func google.golang.org/grpc/credentials/alts.ClientAuthorizationCheck(ctx Context, expectedServiceAccounts []string) error func google.golang.org/grpc/credentials/alts/internal.Handshaker.ClientHandshake(ctx Context) (net.Conn, credentials.AuthInfo, error) func google.golang.org/grpc/credentials/alts/internal.Handshaker.ServerHandshake(ctx Context) (net.Conn, credentials.AuthInfo, error) func google.golang.org/grpc/credentials/alts/internal/handshaker.NewClientHandshaker(ctx Context, conn *grpc.ClientConn, c net.Conn, opts *handshaker.ClientHandshakerOptions) (core.Handshaker, error) func google.golang.org/grpc/credentials/alts/internal/handshaker.NewServerHandshaker(ctx Context, conn *grpc.ClientConn, c net.Conn, opts *handshaker.ServerHandshakerOptions) (core.Handshaker, error) func google.golang.org/grpc/credentials/alts/internal/proto/grpc_gcp.HandshakerServiceClient.DoHandshake(ctx Context, opts ...grpc.CallOption) (grpc_gcp.HandshakerService_DoHandshakeClient, error) func google.golang.org/grpc/credentials/oauth.NewApplicationDefault(ctx Context, scope ...string) (credentials.PerRPCCredentials, error) func google.golang.org/grpc/credentials/oauth.TokenSource.GetRequestMetadata(ctx Context, uri ...string) (map[string]string, error) func google.golang.org/grpc/internal/grpcutil.ExtraMetadata(ctx Context) (md metadata.MD, ok bool) func google.golang.org/grpc/internal/grpcutil.WithExtraMetadata(ctx Context, md metadata.MD) Context func google.golang.org/grpc/internal/transport.NewClientTransport(connectCtx, ctx Context, addr resolver.Address, opts transport.ConnectOptions, onPrefaceReceipt func(), onGoAway func(transport.GoAwayReason), onClose func()) (transport.ClientTransport, error) func google.golang.org/grpc/internal/transport.ClientTransport.NewStream(ctx Context, callHdr *transport.CallHdr) (*transport.Stream, error) func google.golang.org/grpc/metadata.AppendToOutgoingContext(ctx Context, kv ...string) Context func google.golang.org/grpc/metadata.FromIncomingContext(ctx Context) (md metadata.MD, ok bool) func google.golang.org/grpc/metadata.FromOutgoingContext(ctx Context) (metadata.MD, bool) func google.golang.org/grpc/metadata.FromOutgoingContextRaw(ctx Context) (metadata.MD, [][]string, bool) func google.golang.org/grpc/metadata.NewIncomingContext(ctx Context, md metadata.MD) Context func google.golang.org/grpc/metadata.NewOutgoingContext(ctx Context, md metadata.MD) Context func google.golang.org/grpc/peer.FromContext(ctx Context) (p *peer.Peer, ok bool) func google.golang.org/grpc/peer.NewContext(ctx Context, p *peer.Peer) Context func google.golang.org/grpc/stats.OutgoingTags(ctx Context) []byte func google.golang.org/grpc/stats.OutgoingTrace(ctx Context) []byte func google.golang.org/grpc/stats.SetIncomingTags(ctx Context, b []byte) Context func google.golang.org/grpc/stats.SetIncomingTrace(ctx Context, b []byte) Context func google.golang.org/grpc/stats.SetTags(ctx Context, b []byte) Context func google.golang.org/grpc/stats.SetTrace(ctx Context, b []byte) Context func google.golang.org/grpc/stats.Tags(ctx Context) []byte func google.golang.org/grpc/stats.Trace(ctx Context) []byte func google.golang.org/grpc/stats.Handler.HandleConn(Context, stats.ConnStats) func google.golang.org/grpc/stats.Handler.HandleRPC(Context, stats.RPCStats) func google.golang.org/grpc/stats.Handler.TagConn(Context, *stats.ConnTagInfo) Context func google.golang.org/grpc/stats.Handler.TagRPC(Context, *stats.RPCTagInfo) Context func internal/execabs.CommandContext(ctx Context, name string, arg ...string) *exec.Cmd func net.(*Dialer).DialContext(ctx Context, network, address string) (net.Conn, error) func net.(*ListenConfig).Listen(ctx Context, network, address string) (net.Listener, error) func net.(*ListenConfig).ListenPacket(ctx Context, network, address string) (net.PacketConn, error) func net.(*Resolver).LookupAddr(ctx Context, addr string) (names []string, err error) func net.(*Resolver).LookupCNAME(ctx Context, host string) (cname string, err error) func net.(*Resolver).LookupHost(ctx Context, host string) (addrs []string, err error) func net.(*Resolver).LookupIP(ctx Context, network, host string) ([]net.IP, error) func net.(*Resolver).LookupIPAddr(ctx Context, host string) ([]net.IPAddr, error) func net.(*Resolver).LookupMX(ctx Context, name string) ([]*net.MX, error) func net.(*Resolver).LookupNS(ctx Context, name string) ([]*net.NS, error) func net.(*Resolver).LookupPort(ctx Context, network, service string) (port int, err error) func net.(*Resolver).LookupSRV(ctx Context, service, proto, name string) (cname string, addrs []*net.SRV, err error) func net.(*Resolver).LookupTXT(ctx Context, name string) ([]string, error) func net/http.NewRequestWithContext(ctx Context, method, url string, body io.Reader) (*http.Request, error) func net/http.(*Request).Clone(ctx Context) *http.Request func net/http.(*Request).WithContext(ctx Context) *http.Request func net/http.(*Server).Shutdown(ctx Context) error func net/http/httptrace.ContextClientTrace(ctx Context) *httptrace.ClientTrace func net/http/httptrace.WithClientTrace(ctx Context, trace *httptrace.ClientTrace) Context func os/exec.CommandContext(ctx Context, name string, arg ...string) *exec.Cmd func runtime/pprof.Do(ctx Context, labels pprof.LabelSet, f func(Context)) func runtime/pprof.ForLabels(ctx Context, f func(key, value string) bool) func runtime/pprof.Label(ctx Context, key string) (string, bool) func runtime/pprof.SetGoroutineLabels(ctx Context) func runtime/pprof.WithLabels(ctx Context, labels pprof.LabelSet) Context func runtime/trace.Log(ctx Context, category, message string) func runtime/trace.Logf(ctx Context, category, format string, args ...interface{}) func runtime/trace.NewTask(pctx Context, taskType string) (ctx Context, task *trace.Task) func runtime/trace.StartRegion(ctx Context, regionType string) *trace.Region func runtime/trace.WithRegion(ctx Context, regionType string, fn func()) var golang.org/x/oauth2.NoContext
Package-Level Functions (total 13, in which 6 are exported)
Background returns a non-nil, empty Context. It is never canceled, has no values, and has no deadline. It is typically used by the main function, initialization, and tests, and as the top-level Context for incoming requests.
TODO returns a non-nil, empty Context. Code should use context.TODO when it's unclear which Context to use or it is not yet available (because the surrounding function has not yet been extended to accept a Context parameter).
WithCancel returns a copy of parent with a new Done channel. The returned context's Done channel is closed when the returned cancel function is called or when the parent context's Done channel is closed, whichever happens first. Canceling this context releases resources associated with it, so code should call cancel as soon as the operations running in this Context complete.
WithDeadline returns a copy of the parent context with the deadline adjusted to be no later than d. If the parent's deadline is already earlier than d, WithDeadline(parent, d) is semantically equivalent to parent. The returned context's Done channel is closed when the deadline expires, when the returned cancel function is called, or when the parent context's Done channel is closed, whichever happens first. Canceling this context releases resources associated with it, so code should call cancel as soon as the operations running in this Context complete.
WithTimeout returns WithDeadline(parent, time.Now().Add(timeout)). Canceling this context releases resources associated with it, so code should call cancel as soon as the operations running in this Context complete: func slowOperationWithTimeout(ctx context.Context) (Result, error) { ctx, cancel := context.WithTimeout(ctx, 100*time.Millisecond) defer cancel() // releases resources if slowOperation completes before timeout elapses return slowOperation(ctx) }
WithValue returns a copy of parent in which the value associated with key is val. Use context Values only for request-scoped data that transits processes and APIs, not for passing optional parameters to functions. The provided key must be comparable and should not be of type string or any other built-in type to avoid collisions between packages using context. Users of WithValue should define their own types for keys. To avoid allocating when assigning to an interface{}, context keys often have concrete type struct{}. Alternatively, exported context key variables' static type should be a pointer or interface.
Package-Level Variables (total 7, in which 2 are exported)
Canceled is the error returned by Context.Err when the context is canceled.
DeadlineExceeded is the error returned by Context.Err when the context's deadline passes.