package context

Import Path
	context (on go.dev)

Dependency Relation
	imports 5 packages, and imported by 342 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]. A Context may be canceled to indicate that work done on its behalf should stop. A Context with a deadline is canceled after the deadline passes. 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 directly 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. The go vet tool checks that CancelFuncs are used on all control-flow paths. The [WithCancelCause], [WithDeadlineCause], and [WithTimeoutCause] functions return a [CancelCauseFunc], which takes an error and records it as the cancellation cause. Calling [Cause] on the canceled context or any of its children retrieves the cause. If no cause is specified, Cause(ctx) returns the same value as ctx.Err(). 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. This is discussed further in https://go.dev/blog/context-and-structs. 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://go.dev/blog/context for example code for a server that uses Contexts.
Code Examples package main import ( "context" "fmt" "sync" "time" ) func main() { waitOnCond := func(ctx context.Context, cond *sync.Cond, conditionMet func() bool) error { stopf := context.AfterFunc(ctx, func() { // We need to acquire cond.L here to be sure that the Broadcast // below won't occur before the call to Wait, which would result // in a missed signal (and deadlock). cond.L.Lock() defer cond.L.Unlock() // If multiple goroutines are waiting on cond simultaneously, // we need to make sure we wake up exactly this one. // That means that we need to Broadcast to all of the goroutines, // which will wake them all up. // // If there are N concurrent calls to waitOnCond, each of the goroutines // will spuriously wake up O(N) other goroutines that aren't ready yet, // so this will cause the overall CPU cost to be O(N²). cond.Broadcast() }) defer stopf() // Since the wakeups are using Broadcast instead of Signal, this call to // Wait may unblock due to some other goroutine's context being canceled, // so to be sure that ctx is actually canceled we need to check it in a loop. for !conditionMet() { cond.Wait() if ctx.Err() != nil { return ctx.Err() } } return nil } cond := sync.NewCond(new(sync.Mutex)) var wg sync.WaitGroup for i := 0; i < 4; i++ { wg.Add(1) go func() { defer wg.Done() ctx, cancel := context.WithTimeout(context.Background(), 1*time.Millisecond) defer cancel() cond.L.Lock() defer cond.L.Unlock() err := waitOnCond(ctx, cond, func() bool { return false }) fmt.Println(err) }() } wg.Wait() } package main import ( "context" "fmt" "net" "time" ) func main() { readFromConn := func(ctx context.Context, conn net.Conn, b []byte) (n int, err error) { stopc := make(chan struct{}) stop := context.AfterFunc(ctx, func() { conn.SetReadDeadline(time.Now()) close(stopc) }) n, err = conn.Read(b) if !stop() { // The AfterFunc was started. // Wait for it to complete, and reset the Conn's deadline. <-stopc conn.SetReadDeadline(time.Time{}) return n, ctx.Err() } return n, err } listener, err := net.Listen("tcp", "localhost:0") if err != nil { fmt.Println(err) return } defer listener.Close() conn, err := net.Dial(listener.Addr().Network(), listener.Addr().String()) if err != nil { fmt.Println(err) return } defer conn.Close() ctx, cancel := context.WithTimeout(context.Background(), 1*time.Millisecond) defer cancel() b := make([]byte, 1024) _, err = readFromConn(ctx, conn, b) fmt.Println(err) } package main import ( "context" "errors" "fmt" ) func main() { // mergeCancel returns a context that contains the values of ctx, // and which is canceled when either ctx or cancelCtx is canceled. mergeCancel := func(ctx, cancelCtx context.Context) (context.Context, context.CancelFunc) { ctx, cancel := context.WithCancelCause(ctx) stop := context.AfterFunc(cancelCtx, func() { cancel(context.Cause(cancelCtx)) }) return ctx, func() { stop() cancel(context.Canceled) } } ctx1, cancel1 := context.WithCancelCause(context.Background()) defer cancel1(errors.New("ctx1 canceled")) ctx2, cancel2 := context.WithCancelCause(context.Background()) mergedCtx, mergedCancel := mergeCancel(ctx1, ctx2) defer mergedCancel() cancel2(errors.New("ctx2 canceled")) <-mergedCtx.Done() fmt.Println(context.Cause(mergedCtx)) } 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 } } } { d := time.Now().Add(shortDuration) ctx, cancel := context.WithDeadline(context.Background(), d) defer cancel() select { case <-neverReady: fmt.Println("ready") case <-ctx.Done(): fmt.Println(ctx.Err()) } } { ctx, cancel := context.WithTimeout(context.Background(), shortDuration) defer cancel() select { case <-neverReady: fmt.Println("ready") case <-ctx.Done(): fmt.Println(ctx.Err()) } } 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 3)
/* sort by: | */
A CancelCauseFunc behaves like a [CancelFunc] but additionally sets the cancellation cause. This cause can be retrieved by calling [Cause] on the canceled Context or on any of its derived Contexts. If the context has already been canceled, CancelCauseFunc does not set the cause. For example, if childContext is derived from parentContext: - if parentContext is canceled with cause1 before childContext is canceled with cause2, then Cause(parentContext) == Cause(childContext) == cause1 - if childContext is canceled with cause2 before parentContext is canceled with cause1, then Cause(parentContext) == cause1 and Cause(childContext) == cause2 func WithCancelCause(parent Context) (ctx Context, cancel CancelCauseFunc) func github.com/failsafe-go/failsafe-go/internal/util.MergeContexts(ctx1, ctx2 Context) (Context, CancelCauseFunc)
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 WithDeadlineCause(parent Context, d time.Time, cause error) (Context, CancelFunc) func WithTimeout(parent Context, timeout time.Duration) (Context, CancelFunc) func WithTimeoutCause(parent Context, timeout time.Duration, cause error) (Context, CancelFunc) func github.com/benbjohnson/clock.Clock.WithDeadline(parent Context, d time.Time) (Context, CancelFunc) func github.com/benbjohnson/clock.Clock.WithTimeout(parent Context, t time.Duration) (Context, CancelFunc) func github.com/benbjohnson/clock.(*Mock).WithDeadline(parent Context, deadline time.Time) (Context, CancelFunc) func github.com/benbjohnson/clock.(*Mock).WithTimeout(parent Context, timeout time.Duration) (Context, CancelFunc) func github.com/chromedp/chromedp.NewContext(parent Context, opts ...chromedp.ContextOption) (Context, CancelFunc) func github.com/chromedp/chromedp.NewExecAllocator(parent Context, opts ...chromedp.ExecAllocatorOption) (Context, CancelFunc) func github.com/chromedp/chromedp.NewRemoteAllocator(parent Context, url string, opts ...chromedp.RemoteAllocatorOption) (Context, CancelFunc) func github.com/hibiken/asynq/internal/base.(*Cancelations).Get(id string) (fn CancelFunc, ok bool) func github.com/hibiken/asynq/internal/context.New(base Context, msg *base.TaskMessage, deadline time.Time) (Context, CancelFunc) func github.com/pancsta/asyncmachine-go/pkg/machine.(*Subscriptions).ProcessStateCtx(deactivated machine.S) []CancelFunc func github.com/tetratelabs/wazero/internal/wasm.(*ModuleInstance).CloseModuleOnCanceledOrTimeout(ctx Context) CancelFunc func go.uber.org/fx/internal/fxclock.Clock.WithTimeout(Context, time.Duration) (Context, CancelFunc) func go.uber.org/fx/internal/fxclock.(*Mock).WithTimeout(ctx Context, d time.Duration) (Context, CancelFunc) func os/signal.NotifyContext(parent Context, signals ...os.Signal) (ctx Context, stop CancelFunc) func github.com/hibiken/asynq/internal/base.(*Cancelations).Add(id string, fn 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: DeadlineExceeded if the context's deadline passed, or Canceled if the context was canceled for some other reason. 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 } *github.com/francoispqt/gojay.StreamDecoder *github.com/francoispqt/gojay.StreamEncoder github.com/gliderlabs/ssh.Context (interface) github.com/nats-io/nats.go.ContextOpt *github.com/pion/ice/v4.CandidateHost *github.com/pion/ice/v4.CandidatePeerReflexive *github.com/pion/ice/v4.CandidateRelay *github.com/pion/ice/v4.CandidateServerReflexive *github.com/pion/ice/v4/internal/taskloop.Loop *github.com/pion/transport/v2/deadline.Deadline *github.com/pion/transport/v3/deadline.Deadline func Background() Context func TODO() Context func WithCancel(parent Context) (ctx Context, cancel CancelFunc) func WithCancelCause(parent Context) (ctx Context, cancel CancelCauseFunc) func WithDeadline(parent Context, d time.Time) (Context, CancelFunc) func WithDeadlineCause(parent Context, d time.Time, cause error) (Context, CancelFunc) func WithoutCancel(parent Context) Context func WithTimeout(parent Context, timeout time.Duration) (Context, CancelFunc) func WithTimeoutCause(parent Context, timeout time.Duration, cause error) (Context, CancelFunc) func WithValue(parent Context, key, val any) Context func crypto/tls.(*CertificateRequestInfo).Context() Context func crypto/tls.(*ClientHelloInfo).Context() Context func github.com/apache/arrow-go/v18/arrow/compute.SetExecCtx(ctx Context, e compute.ExecCtx) Context func github.com/apache/arrow-go/v18/arrow/compute/exec.WithAllocator(ctx Context, mem memory.Allocator) Context func github.com/apache/thrift/lib/go/thrift.AddReadTHeaderToContext(ctx Context, headers thrift.THeaderMap) Context func github.com/apache/thrift/lib/go/thrift.SetHeader(ctx Context, key, value string) Context func github.com/apache/thrift/lib/go/thrift.SetReadHeaderList(ctx Context, keys []string) Context func github.com/apache/thrift/lib/go/thrift.SetResponseHelper(ctx Context, helper thrift.TResponseHelper) Context func github.com/apache/thrift/lib/go/thrift.SetWriteHeaderList(ctx Context, keys []string) Context func github.com/apache/thrift/lib/go/thrift.UnsetHeader(ctx Context, key string) Context func github.com/benbjohnson/clock.Clock.WithDeadline(parent Context, d time.Time) (Context, CancelFunc) func github.com/benbjohnson/clock.Clock.WithTimeout(parent Context, t time.Duration) (Context, CancelFunc) func github.com/benbjohnson/clock.(*Mock).WithDeadline(parent Context, deadline time.Time) (Context, CancelFunc) func github.com/benbjohnson/clock.(*Mock).WithTimeout(parent Context, timeout time.Duration) (Context, CancelFunc) func github.com/chromedp/cdproto/cdp.WithExecutor(parent Context, executor cdp.Executor) Context func github.com/chromedp/chromedp.NewContext(parent Context, opts ...chromedp.ContextOption) (Context, CancelFunc) func github.com/chromedp/chromedp.NewExecAllocator(parent Context, opts ...chromedp.ExecAllocatorOption) (Context, CancelFunc) func github.com/chromedp/chromedp.NewRemoteAllocator(parent Context, url string, opts ...chromedp.RemoteAllocatorOption) (Context, CancelFunc) func github.com/coder/websocket.(*Conn).CloseRead(ctx Context) Context func github.com/efficientgo/core/testutil.TB.Context() Context func github.com/failsafe-go/failsafe-go.Execution.Context() Context func github.com/failsafe-go/failsafe-go.ExecutionAttempt.Context() Context func github.com/failsafe-go/failsafe-go.ExecutionInfo.Context() Context func github.com/failsafe-go/failsafe-go/internal/util.MergeContexts(ctx1, ctx2 Context) (Context, CancelCauseFunc) func github.com/failsafe-go/failsafe-go/policy.ExecutionInternal.Context() Context func github.com/go-logr/logr.NewContext(ctx Context, logger logr.Logger) Context func github.com/go-logr/logr.NewContextWithSlogLogger(ctx Context, logger *slog.Logger) Context func github.com/goccy/go-json/internal/encoder.SetFieldQueryToContext(ctx Context, query *encoder.FieldQuery) Context func github.com/grpc-ecosystem/grpc-gateway/v2/runtime.AnnotateContext(ctx Context, mux *runtime.ServeMux, req *http.Request, rpcMethodName string, options ...runtime.AnnotateContextOption) (Context, error) func github.com/grpc-ecosystem/grpc-gateway/v2/runtime.AnnotateIncomingContext(ctx Context, mux *runtime.ServeMux, req *http.Request, rpcMethodName string, options ...runtime.AnnotateContextOption) (Context, error) func github.com/grpc-ecosystem/grpc-gateway/v2/runtime.NewServerMetadataContext(ctx Context, md runtime.ServerMetadata) Context func github.com/hibiken/asynq/internal/context.New(base Context, msg *base.TaskMessage, deadline time.Time) (Context, CancelFunc) func github.com/libp2p/go-libp2p/core/network.WithAllowLimitedConn(ctx Context, reason string) Context func github.com/libp2p/go-libp2p/core/network.WithConnManagementScope(ctx Context, scope network.ConnManagementScope) Context func github.com/libp2p/go-libp2p/core/network.WithDialPeerTimeout(ctx Context, timeout time.Duration) Context func github.com/libp2p/go-libp2p/core/network.WithForceDirectDial(ctx Context, reason string) Context func github.com/libp2p/go-libp2p/core/network.WithNoDial(ctx Context, reason string) Context func github.com/libp2p/go-libp2p/core/network.WithSimultaneousConnect(ctx Context, isClient bool, reason string) Context func github.com/libp2p/go-libp2p/core/network.WithUseTransient(ctx Context, reason string) Context func github.com/libp2p/go-libp2p/core/routing.RegisterForQueryEvents(ctx Context) (Context, <-chan *routing.QueryEvent) func github.com/libp2p/go-libp2p/p2p/transport/quicreuse.WithAssociation(ctx Context, association any) Context func github.com/nats-io/nats.go.KeyWatcher.Context() Context func github.com/ncruces/go-sqlite3.(*Conn).GetInterrupt() Context func github.com/ncruces/go-sqlite3.(*Conn).SetInterrupt(ctx Context) (old Context) func github.com/ncruces/go-sqlite3/internal/util.NewContext(ctx Context) Context func github.com/pancsta/asyncmachine-go/examples/benchmark_grpc/proto.WorkerService_SubscribeClient.Context() Context func github.com/pancsta/asyncmachine-go/examples/benchmark_grpc/proto.WorkerService_SubscribeServer.Context() Context func github.com/pancsta/asyncmachine-go/examples/benchmark_grpc/worker_proto.WorkerService_SubscribeClient.Context() Context func github.com/pancsta/asyncmachine-go/examples/benchmark_grpc/worker_proto.WorkerService_SubscribeServer.Context() Context func github.com/pancsta/asyncmachine-go/pkg/history.(*BaseMemory).Context() Context func github.com/pancsta/asyncmachine-go/pkg/history.MemoryApi.Context() Context func github.com/pancsta/asyncmachine-go/pkg/machine.Api.Ctx() Context func github.com/pancsta/asyncmachine-go/pkg/machine.Api.NewStateCtx(state string) Context func github.com/pancsta/asyncmachine-go/pkg/machine.(*Machine).Ctx() Context func github.com/pancsta/asyncmachine-go/pkg/machine.(*Machine).NewStateCtx(state string) Context func github.com/pancsta/asyncmachine-go/pkg/machine.(*NoOpTracer).MachineInit(machine machine.Api) Context func github.com/pancsta/asyncmachine-go/pkg/machine.(*Subscriptions).NewStateCtx(state string) Context func github.com/pancsta/asyncmachine-go/pkg/machine.Tracer.MachineInit(machine machine.Api) Context func github.com/pancsta/asyncmachine-go/pkg/rpc.(*Worker).Ctx() Context func github.com/pancsta/asyncmachine-go/pkg/rpc.(*Worker).NewStateCtx(state string) Context func github.com/pancsta/asyncmachine-go/pkg/telemetry.(*DbgTracer).MachineInit(mach am.Api) Context func github.com/pancsta/asyncmachine-go/pkg/telemetry.(*OtelMachTracer).MachineInit(mach am.Api) Context func github.com/pancsta/asyncmachine-go/pkg/x/history/frostdb.(*Tracer).MachineInit(mach am.Api) Context func github.com/pancsta/asyncmachine-go/tools/generator.(*SyncTracer).MachineInit(mach am.Api) Context func github.com/quic-go/quic-go.Connection.Context() Context func github.com/quic-go/quic-go.EarlyConnection.Context() Context func github.com/quic-go/quic-go.SendStream.Context() Context func github.com/quic-go/quic-go.Stream.Context() Context func github.com/quic-go/quic-go/http3.Connection.Context() Context func github.com/quic-go/quic-go/http3.RequestStream.Context() Context func github.com/quic-go/quic-go/http3.Stream.Context() Context func github.com/quic-go/webtransport-go.(*Session).Context() Context func github.com/robfig/cron/v3.(*Cron).Stop() Context func github.com/spf13/cobra.(*Command).Context() Context func github.com/tetratelabs/wazero/experimental.WithCloseNotifier(ctx Context, notifier experimental.CloseNotifier) Context func github.com/tetratelabs/wazero/experimental.WithFunctionListenerFactory(ctx Context, factory experimental.FunctionListenerFactory) Context func github.com/tetratelabs/wazero/experimental.WithImportResolver(ctx Context, resolver experimental.ImportResolver) Context func github.com/tetratelabs/wazero/experimental.WithMemoryAllocator(ctx Context, allocator experimental.MemoryAllocator) Context func github.com/tetratelabs/wazero/experimental.WithSnapshotter(ctx Context) Context func github.com/tetratelabs/wazero/internal/engine/wazevo/wazevoapi.NewDeterministicCompilationVerifierContext(ctx Context, localFunctions int) Context func github.com/tetratelabs/wazero/internal/engine/wazevo/wazevoapi.SetCurrentFunctionName(ctx Context, index int, functionName string) Context func go.opentelemetry.io/otel/baggage.ContextWithBaggage(parent Context, b baggage.Baggage) Context func go.opentelemetry.io/otel/baggage.ContextWithoutBaggage(parent Context) Context func go.opentelemetry.io/otel/internal/baggage.ContextWithGetHook(parent Context, hook baggage.GetHookFunc) Context func go.opentelemetry.io/otel/internal/baggage.ContextWithList(parent Context, list baggage.List) Context func go.opentelemetry.io/otel/internal/baggage.ContextWithSetHook(parent Context, hook baggage.SetHookFunc) Context func go.opentelemetry.io/otel/propagation.Baggage.Extract(parent Context, carrier propagation.TextMapCarrier) Context func go.opentelemetry.io/otel/propagation.TextMapPropagator.Extract(ctx Context, carrier propagation.TextMapCarrier) Context func go.opentelemetry.io/otel/propagation.TraceContext.Extract(ctx Context, carrier propagation.TextMapCarrier) Context func go.opentelemetry.io/otel/trace.ContextWithRemoteSpanContext(parent Context, rsc trace.SpanContext) Context func go.opentelemetry.io/otel/trace.ContextWithSpan(parent Context, span trace.Span) Context func go.opentelemetry.io/otel/trace.ContextWithSpanContext(parent Context, sc trace.SpanContext) Context func go.opentelemetry.io/otel/trace.Tracer.Start(ctx Context, spanName string, opts ...trace.SpanStartOption) (Context, trace.Span) func go.opentelemetry.io/otel/trace/noop.Tracer.Start(ctx Context, _ string, _ ...trace.SpanStartOption) (Context, trace.Span) func go.uber.org/fx/internal/fxclock.Clock.WithTimeout(Context, time.Duration) (Context, CancelFunc) func go.uber.org/fx/internal/fxclock.(*Mock).WithTimeout(ctx Context, d time.Duration) (Context, CancelFunc) func golang.org/x/net/trace.NewContext(ctx Context, tr trace.Trace) 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.BidiStreamingClient.Context() Context func google.golang.org/grpc.BidiStreamingServer.Context() Context func google.golang.org/grpc.ClientStream.Context() Context func google.golang.org/grpc.ClientStreamingClient.Context() Context func google.golang.org/grpc.ClientStreamingServer.Context() Context func google.golang.org/grpc.ServerStream.Context() Context func google.golang.org/grpc.ServerStreamingClient.Context() Context func google.golang.org/grpc.ServerStreamingServer.Context() Context func google.golang.org/grpc.Stream.Context() Context func google.golang.org/grpc/credentials.NewContextWithRequestInfo(ctx Context, ri credentials.RequestInfo) Context func google.golang.org/grpc/health/grpc_health_v1.Health_WatchClient.Context() Context func google.golang.org/grpc/health/grpc_health_v1.Health_WatchServer.Context() Context func google.golang.org/grpc/internal/credentials.NewClientHandshakeInfoContext(ctx Context, chi any) Context func google.golang.org/grpc/internal/grpcutil.WithExtraMetadata(ctx Context, md metadata.MD) Context func google.golang.org/grpc/internal/resolver.ClientStream.Context() Context func google.golang.org/grpc/internal/stats.SetLabels(ctx Context, labels *stats.Labels) Context func google.golang.org/grpc/internal/transport.SetConnection(ctx Context, conn net.Conn) 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.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 os/signal.NotifyContext(parent Context, signals ...os.Signal) (ctx Context, stop CancelFunc) func oss.terrastruct.com/d2/lib/log.Leveled(ctx Context, level slog.Level) Context func oss.terrastruct.com/d2/lib/log.With(ctx Context, l *slog.Logger) Context func oss.terrastruct.com/d2/lib/log.WithDefault(ctx Context) Context func oss.terrastruct.com/d2/lib/log.WithTB(ctx Context, tb testing.TB) 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 testing.TB.Context() Context func AfterFunc(ctx Context, f func()) (stop func() bool) func Cause(c Context) error func WithCancel(parent Context) (ctx Context, cancel CancelFunc) func WithCancelCause(parent Context) (ctx Context, cancel CancelCauseFunc) func WithDeadline(parent Context, d time.Time) (Context, CancelFunc) func WithDeadlineCause(parent Context, d time.Time, cause error) (Context, CancelFunc) func WithoutCancel(parent Context) Context func WithTimeout(parent Context, timeout time.Duration) (Context, CancelFunc) func WithTimeoutCause(parent Context, timeout time.Duration, cause error) (Context, CancelFunc) func WithValue(parent Context, key, val any) Context func crypto/tls.(*Conn).HandshakeContext(ctx Context) error func crypto/tls.(*Dialer).DialContext(ctx Context, network, addr string) (net.Conn, error) func crypto/tls.(*QUICConn).Start(ctx Context) error func database/sql.(*Conn).BeginTx(ctx Context, opts *sql.TxOptions) (*sql.Tx, error) func database/sql.(*Conn).ExecContext(ctx Context, query string, args ...any) (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 ...any) (*sql.Rows, error) func database/sql.(*Conn).QueryRowContext(ctx Context, query string, args ...any) *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 ...any) (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 ...any) (*sql.Rows, error) func database/sql.(*DB).QueryRowContext(ctx Context, query string, args ...any) *sql.Row func database/sql.(*Stmt).ExecContext(ctx Context, args ...any) (sql.Result, error) func database/sql.(*Stmt).QueryContext(ctx Context, args ...any) (*sql.Rows, error) func database/sql.(*Stmt).QueryRowContext(ctx Context, args ...any) *sql.Row func database/sql.(*Tx).ExecContext(ctx Context, query string, args ...any) (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 ...any) (*sql.Rows, error) func database/sql.(*Tx).QueryRowContext(ctx Context, query string, args ...any) *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/apache/arrow-go/v18/arrow/compute.AbsoluteValue(ctx Context, opts compute.ArithmeticOptions, input compute.Datum) (compute.Datum, error) func github.com/apache/arrow-go/v18/arrow/compute.Acos(ctx Context, opts compute.ArithmeticOptions, arg compute.Datum) (compute.Datum, error) func github.com/apache/arrow-go/v18/arrow/compute.Add(ctx Context, opts compute.ArithmeticOptions, left, right compute.Datum) (compute.Datum, error) func github.com/apache/arrow-go/v18/arrow/compute.Asin(ctx Context, opts compute.ArithmeticOptions, arg compute.Datum) (compute.Datum, error) func github.com/apache/arrow-go/v18/arrow/compute.Atan(ctx Context, arg compute.Datum) (compute.Datum, error) func github.com/apache/arrow-go/v18/arrow/compute.Atan2(ctx Context, x, y compute.Datum) (compute.Datum, error) func github.com/apache/arrow-go/v18/arrow/compute.CallFunction(ctx Context, funcName string, opts compute.FunctionOptions, args ...compute.Datum) (compute.Datum, error) func github.com/apache/arrow-go/v18/arrow/compute.CastArray(ctx Context, val arrow.Array, opts *compute.CastOptions) (arrow.Array, error) func github.com/apache/arrow-go/v18/arrow/compute.CastDatum(ctx Context, val compute.Datum, opts *compute.CastOptions) (compute.Datum, error) func github.com/apache/arrow-go/v18/arrow/compute.CastToType(ctx Context, val arrow.Array, toType arrow.DataType) (arrow.Array, error) func github.com/apache/arrow-go/v18/arrow/compute.Cos(ctx Context, opts compute.ArithmeticOptions, arg compute.Datum) (compute.Datum, error) func github.com/apache/arrow-go/v18/arrow/compute.Divide(ctx Context, opts compute.ArithmeticOptions, left, right compute.Datum) (compute.Datum, error) func github.com/apache/arrow-go/v18/arrow/compute.Filter(ctx Context, values, filter compute.Datum, options compute.FilterOptions) (compute.Datum, error) func github.com/apache/arrow-go/v18/arrow/compute.FilterArray(ctx Context, values, filter arrow.Array, options compute.FilterOptions) (arrow.Array, error) func github.com/apache/arrow-go/v18/arrow/compute.FilterRecordBatch(ctx Context, batch arrow.RecordBatch, filter arrow.Array, opts *compute.FilterOptions) (arrow.RecordBatch, error) func github.com/apache/arrow-go/v18/arrow/compute.FilterTable(ctx Context, tbl arrow.Table, filter compute.Datum, opts *compute.FilterOptions) (arrow.Table, error) func github.com/apache/arrow-go/v18/arrow/compute.GetExecCtx(ctx Context) compute.ExecCtx func github.com/apache/arrow-go/v18/arrow/compute.IsIn(ctx Context, opts compute.SetOptions, values compute.Datum) (compute.Datum, error) func github.com/apache/arrow-go/v18/arrow/compute.IsInSet(ctx Context, valueSet, values compute.Datum) (compute.Datum, error) func github.com/apache/arrow-go/v18/arrow/compute.Ln(ctx Context, opts compute.ArithmeticOptions, arg compute.Datum) (compute.Datum, error) func github.com/apache/arrow-go/v18/arrow/compute.Log10(ctx Context, opts compute.ArithmeticOptions, arg compute.Datum) (compute.Datum, error) func github.com/apache/arrow-go/v18/arrow/compute.Log1p(ctx Context, opts compute.ArithmeticOptions, arg compute.Datum) (compute.Datum, error) func github.com/apache/arrow-go/v18/arrow/compute.Log2(ctx Context, opts compute.ArithmeticOptions, arg compute.Datum) (compute.Datum, error) func github.com/apache/arrow-go/v18/arrow/compute.Logb(ctx Context, opts compute.ArithmeticOptions, x, base compute.Datum) (compute.Datum, error) func github.com/apache/arrow-go/v18/arrow/compute.Multiply(ctx Context, opts compute.ArithmeticOptions, left, right compute.Datum) (compute.Datum, error) func github.com/apache/arrow-go/v18/arrow/compute.Negate(ctx Context, opts compute.ArithmeticOptions, input compute.Datum) (compute.Datum, error) func github.com/apache/arrow-go/v18/arrow/compute.Power(ctx Context, opts compute.ArithmeticOptions, base, exp compute.Datum) (compute.Datum, error) func github.com/apache/arrow-go/v18/arrow/compute.Round(ctx Context, opts compute.RoundOptions, arg compute.Datum) (compute.Datum, error) func github.com/apache/arrow-go/v18/arrow/compute.RoundToMultiple(ctx Context, opts compute.RoundToMultipleOptions, arg compute.Datum) (compute.Datum, error) func github.com/apache/arrow-go/v18/arrow/compute.RunEndDecode(ctx Context, arg compute.Datum) (compute.Datum, error) func github.com/apache/arrow-go/v18/arrow/compute.RunEndDecodeArray(ctx Context, input arrow.Array) (arrow.Array, error) func github.com/apache/arrow-go/v18/arrow/compute.RunEndEncode(ctx Context, opts compute.RunEndEncodeOptions, arg compute.Datum) (compute.Datum, error) func github.com/apache/arrow-go/v18/arrow/compute.RunEndEncodeArray(ctx Context, opts compute.RunEndEncodeOptions, input arrow.Array) (arrow.Array, error) func github.com/apache/arrow-go/v18/arrow/compute.SetExecCtx(ctx Context, e compute.ExecCtx) Context func github.com/apache/arrow-go/v18/arrow/compute.ShiftLeft(ctx Context, opts compute.ArithmeticOptions, lhs, rhs compute.Datum) (compute.Datum, error) func github.com/apache/arrow-go/v18/arrow/compute.ShiftRight(ctx Context, opts compute.ArithmeticOptions, lhs, rhs compute.Datum) (compute.Datum, error) func github.com/apache/arrow-go/v18/arrow/compute.Sign(ctx Context, input compute.Datum) (compute.Datum, error) func github.com/apache/arrow-go/v18/arrow/compute.Sin(ctx Context, opts compute.ArithmeticOptions, arg compute.Datum) (compute.Datum, error) func github.com/apache/arrow-go/v18/arrow/compute.Subtract(ctx Context, opts compute.ArithmeticOptions, left, right compute.Datum) (compute.Datum, error) func github.com/apache/arrow-go/v18/arrow/compute.Take(ctx Context, opts compute.TakeOptions, values, indices compute.Datum) (compute.Datum, error) func github.com/apache/arrow-go/v18/arrow/compute.TakeArray(ctx Context, values, indices arrow.Array) (arrow.Array, error) func github.com/apache/arrow-go/v18/arrow/compute.TakeArrayOpts(ctx Context, values, indices arrow.Array, opts compute.TakeOptions) (arrow.Array, error) func github.com/apache/arrow-go/v18/arrow/compute.Tan(ctx Context, opts compute.ArithmeticOptions, arg compute.Datum) (compute.Datum, error) func github.com/apache/arrow-go/v18/arrow/compute.Unique(ctx Context, values compute.Datum) (compute.Datum, error) func github.com/apache/arrow-go/v18/arrow/compute.UniqueArray(ctx Context, values arrow.Array) (arrow.Array, error) func github.com/apache/arrow-go/v18/arrow/compute.Function.Execute(Context, compute.FunctionOptions, ...compute.Datum) (compute.Datum, error) func github.com/apache/arrow-go/v18/arrow/compute.KernelExecutor.Execute(Context, *compute.ExecBatch, chan<- compute.Datum) error func github.com/apache/arrow-go/v18/arrow/compute.KernelExecutor.WrapResults(ctx Context, out <-chan compute.Datum, chunkedArgs bool) compute.Datum func github.com/apache/arrow-go/v18/arrow/compute.(*MetaFunction).Execute(ctx Context, opts compute.FunctionOptions, args ...compute.Datum) (compute.Datum, error) func github.com/apache/arrow-go/v18/arrow/compute.(*ScalarFunction).Execute(ctx Context, opts compute.FunctionOptions, args ...compute.Datum) (compute.Datum, error) func github.com/apache/arrow-go/v18/arrow/compute.(*VectorFunction).Execute(ctx Context, opts compute.FunctionOptions, args ...compute.Datum) (compute.Datum, error) func github.com/apache/arrow-go/v18/arrow/compute/exec.GetAllocator(ctx Context) memory.Allocator func github.com/apache/arrow-go/v18/arrow/compute/exec.WithAllocator(ctx Context, mem memory.Allocator) Context func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*AesGcmCtrV1).Read(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*AesGcmCtrV1).ReadField1(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*AesGcmCtrV1).ReadField2(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*AesGcmCtrV1).ReadField3(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*AesGcmCtrV1).Write(ctx Context, oprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*AesGcmV1).Read(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*AesGcmV1).ReadField1(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*AesGcmV1).ReadField2(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*AesGcmV1).ReadField3(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*AesGcmV1).Write(ctx Context, oprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*BloomFilterAlgorithm).Read(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*BloomFilterAlgorithm).ReadField1(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*BloomFilterAlgorithm).Write(ctx Context, oprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*BloomFilterCompression).Read(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*BloomFilterCompression).ReadField1(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*BloomFilterCompression).Write(ctx Context, oprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*BloomFilterHash).Read(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*BloomFilterHash).ReadField1(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*BloomFilterHash).Write(ctx Context, oprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*BloomFilterHeader).Read(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*BloomFilterHeader).ReadField1(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*BloomFilterHeader).ReadField2(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*BloomFilterHeader).ReadField3(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*BloomFilterHeader).ReadField4(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*BloomFilterHeader).Write(ctx Context, oprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*BoundingBox).Read(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*BoundingBox).ReadField1(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*BoundingBox).ReadField2(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*BoundingBox).ReadField3(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*BoundingBox).ReadField4(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*BoundingBox).ReadField5(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*BoundingBox).ReadField6(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*BoundingBox).ReadField7(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*BoundingBox).ReadField8(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*BoundingBox).Write(ctx Context, oprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*BsonType).Read(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*BsonType).Write(ctx Context, oprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*ColumnChunk).Read(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*ColumnChunk).ReadField1(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*ColumnChunk).ReadField2(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*ColumnChunk).ReadField3(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*ColumnChunk).ReadField4(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*ColumnChunk).ReadField5(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*ColumnChunk).ReadField6(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*ColumnChunk).ReadField7(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*ColumnChunk).ReadField8(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*ColumnChunk).ReadField9(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*ColumnChunk).Write(ctx Context, oprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*ColumnCryptoMetaData).Read(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*ColumnCryptoMetaData).ReadField1(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*ColumnCryptoMetaData).ReadField2(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*ColumnCryptoMetaData).Write(ctx Context, oprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*ColumnIndex).Read(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*ColumnIndex).ReadField1(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*ColumnIndex).ReadField2(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*ColumnIndex).ReadField3(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*ColumnIndex).ReadField4(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*ColumnIndex).ReadField5(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*ColumnIndex).ReadField6(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*ColumnIndex).ReadField7(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*ColumnIndex).Write(ctx Context, oprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*ColumnMetaData).Read(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*ColumnMetaData).ReadField1(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*ColumnMetaData).ReadField10(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*ColumnMetaData).ReadField11(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*ColumnMetaData).ReadField12(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*ColumnMetaData).ReadField13(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*ColumnMetaData).ReadField14(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*ColumnMetaData).ReadField15(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*ColumnMetaData).ReadField16(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*ColumnMetaData).ReadField17(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*ColumnMetaData).ReadField2(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*ColumnMetaData).ReadField3(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*ColumnMetaData).ReadField4(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*ColumnMetaData).ReadField5(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*ColumnMetaData).ReadField6(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*ColumnMetaData).ReadField7(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*ColumnMetaData).ReadField8(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*ColumnMetaData).ReadField9(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*ColumnMetaData).Write(ctx Context, oprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*ColumnOrder).Read(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*ColumnOrder).ReadField1(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*ColumnOrder).Write(ctx Context, oprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*DataPageHeader).Read(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*DataPageHeader).ReadField1(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*DataPageHeader).ReadField2(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*DataPageHeader).ReadField3(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*DataPageHeader).ReadField4(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*DataPageHeader).ReadField5(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*DataPageHeader).Write(ctx Context, oprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*DataPageHeaderV2).Read(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*DataPageHeaderV2).ReadField1(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*DataPageHeaderV2).ReadField2(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*DataPageHeaderV2).ReadField3(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*DataPageHeaderV2).ReadField4(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*DataPageHeaderV2).ReadField5(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*DataPageHeaderV2).ReadField6(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*DataPageHeaderV2).ReadField7(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*DataPageHeaderV2).ReadField8(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*DataPageHeaderV2).Write(ctx Context, oprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*DateType).Read(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*DateType).Write(ctx Context, oprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*DecimalType).Read(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*DecimalType).ReadField1(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*DecimalType).ReadField2(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*DecimalType).Write(ctx Context, oprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*DictionaryPageHeader).Read(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*DictionaryPageHeader).ReadField1(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*DictionaryPageHeader).ReadField2(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*DictionaryPageHeader).ReadField3(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*DictionaryPageHeader).Write(ctx Context, oprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*EncryptionAlgorithm).Read(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*EncryptionAlgorithm).ReadField1(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*EncryptionAlgorithm).ReadField2(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*EncryptionAlgorithm).Write(ctx Context, oprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*EncryptionWithColumnKey).Read(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*EncryptionWithColumnKey).ReadField1(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*EncryptionWithColumnKey).ReadField2(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*EncryptionWithColumnKey).Write(ctx Context, oprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*EncryptionWithFooterKey).Read(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*EncryptionWithFooterKey).Write(ctx Context, oprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*EnumType).Read(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*EnumType).Write(ctx Context, oprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*FileCryptoMetaData).Read(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*FileCryptoMetaData).ReadField1(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*FileCryptoMetaData).ReadField2(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*FileCryptoMetaData).Write(ctx Context, oprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*FileMetaData).Read(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*FileMetaData).ReadField1(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*FileMetaData).ReadField2(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*FileMetaData).ReadField3(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*FileMetaData).ReadField4(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*FileMetaData).ReadField5(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*FileMetaData).ReadField6(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*FileMetaData).ReadField7(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*FileMetaData).ReadField8(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*FileMetaData).ReadField9(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*FileMetaData).Write(ctx Context, oprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*Float16Type).Read(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*Float16Type).Write(ctx Context, oprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*GeographyType).Read(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*GeographyType).ReadField1(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*GeographyType).ReadField2(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*GeographyType).Write(ctx Context, oprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*GeometryType).Read(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*GeometryType).ReadField1(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*GeometryType).Write(ctx Context, oprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*GeospatialStatistics).Read(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*GeospatialStatistics).ReadField1(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*GeospatialStatistics).ReadField2(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*GeospatialStatistics).Write(ctx Context, oprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*IndexPageHeader).Read(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*IndexPageHeader).Write(ctx Context, oprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*IntType).Read(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*IntType).ReadField1(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*IntType).ReadField2(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*IntType).Write(ctx Context, oprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*JsonType).Read(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*JsonType).Write(ctx Context, oprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*KeyValue).Read(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*KeyValue).ReadField1(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*KeyValue).ReadField2(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*KeyValue).Write(ctx Context, oprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*ListType).Read(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*ListType).Write(ctx Context, oprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*LogicalType).Read(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*LogicalType).ReadField1(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*LogicalType).ReadField10(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*LogicalType).ReadField11(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*LogicalType).ReadField12(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*LogicalType).ReadField13(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*LogicalType).ReadField14(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*LogicalType).ReadField15(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*LogicalType).ReadField16(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*LogicalType).ReadField17(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*LogicalType).ReadField18(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*LogicalType).ReadField2(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*LogicalType).ReadField3(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*LogicalType).ReadField4(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*LogicalType).ReadField5(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*LogicalType).ReadField6(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*LogicalType).ReadField7(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*LogicalType).ReadField8(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*LogicalType).Write(ctx Context, oprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*MapType).Read(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*MapType).Write(ctx Context, oprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*MicroSeconds).Read(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*MicroSeconds).Write(ctx Context, oprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*MilliSeconds).Read(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*MilliSeconds).Write(ctx Context, oprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*NanoSeconds).Read(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*NanoSeconds).Write(ctx Context, oprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*NullType).Read(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*NullType).Write(ctx Context, oprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*OffsetIndex).Read(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*OffsetIndex).ReadField1(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*OffsetIndex).ReadField2(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*OffsetIndex).Write(ctx Context, oprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*PageEncodingStats).Read(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*PageEncodingStats).ReadField1(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*PageEncodingStats).ReadField2(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*PageEncodingStats).ReadField3(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*PageEncodingStats).Write(ctx Context, oprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*PageHeader).Read(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*PageHeader).ReadField1(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*PageHeader).ReadField2(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*PageHeader).ReadField3(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*PageHeader).ReadField4(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*PageHeader).ReadField5(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*PageHeader).ReadField6(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*PageHeader).ReadField7(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*PageHeader).ReadField8(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*PageHeader).Write(ctx Context, oprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*PageLocation).Read(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*PageLocation).ReadField1(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*PageLocation).ReadField2(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*PageLocation).ReadField3(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*PageLocation).Write(ctx Context, oprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*RowGroup).Read(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*RowGroup).ReadField1(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*RowGroup).ReadField2(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*RowGroup).ReadField3(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*RowGroup).ReadField4(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*RowGroup).ReadField5(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*RowGroup).ReadField6(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*RowGroup).ReadField7(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*RowGroup).Write(ctx Context, oprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*SchemaElement).Read(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*SchemaElement).ReadField1(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*SchemaElement).ReadField10(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*SchemaElement).ReadField2(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*SchemaElement).ReadField3(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*SchemaElement).ReadField4(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*SchemaElement).ReadField5(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*SchemaElement).ReadField6(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*SchemaElement).ReadField7(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*SchemaElement).ReadField8(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*SchemaElement).ReadField9(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*SchemaElement).Write(ctx Context, oprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*SizeStatistics).Read(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*SizeStatistics).ReadField1(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*SizeStatistics).ReadField2(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*SizeStatistics).ReadField3(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*SizeStatistics).Write(ctx Context, oprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*SortingColumn).Read(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*SortingColumn).ReadField1(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*SortingColumn).ReadField2(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*SortingColumn).ReadField3(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*SortingColumn).Write(ctx Context, oprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*SplitBlockAlgorithm).Read(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*SplitBlockAlgorithm).Write(ctx Context, oprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*Statistics).Read(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*Statistics).ReadField1(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*Statistics).ReadField2(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*Statistics).ReadField3(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*Statistics).ReadField4(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*Statistics).ReadField5(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*Statistics).ReadField6(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*Statistics).ReadField7(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*Statistics).ReadField8(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*Statistics).Write(ctx Context, oprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*StringType).Read(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*StringType).Write(ctx Context, oprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*TimestampType).Read(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*TimestampType).ReadField1(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*TimestampType).ReadField2(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*TimestampType).Write(ctx Context, oprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*TimeType).Read(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*TimeType).ReadField1(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*TimeType).ReadField2(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*TimeType).Write(ctx Context, oprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*TimeUnit).Read(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*TimeUnit).ReadField1(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*TimeUnit).ReadField2(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*TimeUnit).ReadField3(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*TimeUnit).Write(ctx Context, oprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*TypeDefinedOrder).Read(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*TypeDefinedOrder).Write(ctx Context, oprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*Uncompressed).Read(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*Uncompressed).Write(ctx Context, oprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*UUIDType).Read(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*UUIDType).Write(ctx Context, oprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*VariantType).Read(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*VariantType).ReadField1(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*VariantType).Write(ctx Context, oprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*XxHash).Read(ctx Context, iprot thrift.TProtocol) error func github.com/apache/arrow-go/v18/parquet/internal/gen-go/parquet.(*XxHash).Write(ctx Context, oprot thrift.TProtocol) error func github.com/apache/thrift/lib/go/thrift.AddReadTHeaderToContext(ctx Context, headers thrift.THeaderMap) Context func github.com/apache/thrift/lib/go/thrift.GetHeader(ctx Context, key string) (value string, ok bool) func github.com/apache/thrift/lib/go/thrift.GetReadHeaderList(ctx Context) []string func github.com/apache/thrift/lib/go/thrift.GetResponseHelper(ctx Context) (helper thrift.TResponseHelper, ok bool) func github.com/apache/thrift/lib/go/thrift.GetWriteHeaderList(ctx Context) []string func github.com/apache/thrift/lib/go/thrift.SetHeader(ctx Context, key, value string) Context func github.com/apache/thrift/lib/go/thrift.SetReadHeaderList(ctx Context, keys []string) Context func github.com/apache/thrift/lib/go/thrift.SetResponseHelper(ctx Context, helper thrift.TResponseHelper) Context func github.com/apache/thrift/lib/go/thrift.SetWriteHeaderList(ctx Context, keys []string) Context func github.com/apache/thrift/lib/go/thrift.Skip(ctx Context, self thrift.TProtocol, fieldType thrift.TType, maxDepth int) (err error) func github.com/apache/thrift/lib/go/thrift.SkipDefaultDepth(ctx Context, prot thrift.TProtocol, typeId thrift.TType) (err error) func github.com/apache/thrift/lib/go/thrift.UnsetHeader(ctx Context, key string) Context func github.com/apache/thrift/lib/go/thrift.ContextFlusher.Flush(ctx Context) (err error) func github.com/apache/thrift/lib/go/thrift.(*StreamTransport).Flush(ctx Context) error func github.com/apache/thrift/lib/go/thrift.TApplicationException.Read(ctx Context, iprot thrift.TProtocol) error func github.com/apache/thrift/lib/go/thrift.TApplicationException.Write(ctx Context, oprot thrift.TProtocol) error func github.com/apache/thrift/lib/go/thrift.(*TBinaryProtocol).Flush(ctx Context) (err error) func github.com/apache/thrift/lib/go/thrift.(*TBinaryProtocol).ReadBinary(ctx Context) ([]byte, error) func github.com/apache/thrift/lib/go/thrift.(*TBinaryProtocol).ReadBool(ctx Context) (bool, error) func github.com/apache/thrift/lib/go/thrift.(*TBinaryProtocol).ReadByte(ctx Context) (int8, error) func github.com/apache/thrift/lib/go/thrift.(*TBinaryProtocol).ReadDouble(ctx Context) (value float64, err error) func github.com/apache/thrift/lib/go/thrift.(*TBinaryProtocol).ReadFieldBegin(ctx Context) (name string, typeId thrift.TType, seqId int16, err error) func github.com/apache/thrift/lib/go/thrift.(*TBinaryProtocol).ReadFieldEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TBinaryProtocol).ReadI16(ctx Context) (value int16, err error) func github.com/apache/thrift/lib/go/thrift.(*TBinaryProtocol).ReadI32(ctx Context) (value int32, err error) func github.com/apache/thrift/lib/go/thrift.(*TBinaryProtocol).ReadI64(ctx Context) (value int64, err error) func github.com/apache/thrift/lib/go/thrift.(*TBinaryProtocol).ReadListBegin(ctx Context) (elemType thrift.TType, size int, err error) func github.com/apache/thrift/lib/go/thrift.(*TBinaryProtocol).ReadListEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TBinaryProtocol).ReadMapBegin(ctx Context) (kType, vType thrift.TType, size int, err error) func github.com/apache/thrift/lib/go/thrift.(*TBinaryProtocol).ReadMapEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TBinaryProtocol).ReadMessageBegin(ctx Context) (name string, typeId thrift.TMessageType, seqId int32, err error) func github.com/apache/thrift/lib/go/thrift.(*TBinaryProtocol).ReadMessageEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TBinaryProtocol).ReadSetBegin(ctx Context) (elemType thrift.TType, size int, err error) func github.com/apache/thrift/lib/go/thrift.(*TBinaryProtocol).ReadSetEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TBinaryProtocol).ReadString(ctx Context) (value string, err error) func github.com/apache/thrift/lib/go/thrift.(*TBinaryProtocol).ReadStructBegin(ctx Context) (name string, err error) func github.com/apache/thrift/lib/go/thrift.(*TBinaryProtocol).ReadStructEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TBinaryProtocol).ReadUUID(ctx Context) (value thrift.Tuuid, err error) func github.com/apache/thrift/lib/go/thrift.(*TBinaryProtocol).Skip(ctx Context, fieldType thrift.TType) (err error) func github.com/apache/thrift/lib/go/thrift.(*TBinaryProtocol).WriteBinary(ctx Context, value []byte) error func github.com/apache/thrift/lib/go/thrift.(*TBinaryProtocol).WriteBool(ctx Context, value bool) error func github.com/apache/thrift/lib/go/thrift.(*TBinaryProtocol).WriteByte(ctx Context, value int8) error func github.com/apache/thrift/lib/go/thrift.(*TBinaryProtocol).WriteDouble(ctx Context, value float64) error func github.com/apache/thrift/lib/go/thrift.(*TBinaryProtocol).WriteFieldBegin(ctx Context, name string, typeId thrift.TType, id int16) error func github.com/apache/thrift/lib/go/thrift.(*TBinaryProtocol).WriteFieldEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TBinaryProtocol).WriteFieldStop(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TBinaryProtocol).WriteI16(ctx Context, value int16) error func github.com/apache/thrift/lib/go/thrift.(*TBinaryProtocol).WriteI32(ctx Context, value int32) error func github.com/apache/thrift/lib/go/thrift.(*TBinaryProtocol).WriteI64(ctx Context, value int64) error func github.com/apache/thrift/lib/go/thrift.(*TBinaryProtocol).WriteListBegin(ctx Context, elemType thrift.TType, size int) error func github.com/apache/thrift/lib/go/thrift.(*TBinaryProtocol).WriteListEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TBinaryProtocol).WriteMapBegin(ctx Context, keyType thrift.TType, valueType thrift.TType, size int) error func github.com/apache/thrift/lib/go/thrift.(*TBinaryProtocol).WriteMapEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TBinaryProtocol).WriteMessageBegin(ctx Context, name string, typeId thrift.TMessageType, seqId int32) error func github.com/apache/thrift/lib/go/thrift.(*TBinaryProtocol).WriteMessageEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TBinaryProtocol).WriteSetBegin(ctx Context, elemType thrift.TType, size int) error func github.com/apache/thrift/lib/go/thrift.(*TBinaryProtocol).WriteSetEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TBinaryProtocol).WriteString(ctx Context, value string) error func github.com/apache/thrift/lib/go/thrift.(*TBinaryProtocol).WriteStructBegin(ctx Context, name string) error func github.com/apache/thrift/lib/go/thrift.(*TBinaryProtocol).WriteStructEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TBinaryProtocol).WriteUUID(ctx Context, value thrift.Tuuid) error func github.com/apache/thrift/lib/go/thrift.(*TBufferedTransport).Flush(ctx Context) error func github.com/apache/thrift/lib/go/thrift.TClient.Call(ctx Context, method string, args, result thrift.TStruct) (thrift.ResponseMeta, error) func github.com/apache/thrift/lib/go/thrift.(*TCompactProtocol).Flush(ctx Context) (err error) func github.com/apache/thrift/lib/go/thrift.(*TCompactProtocol).ReadBinary(ctx Context) (value []byte, err error) func github.com/apache/thrift/lib/go/thrift.(*TCompactProtocol).ReadBool(ctx Context) (value bool, err error) func github.com/apache/thrift/lib/go/thrift.(*TCompactProtocol).ReadByte(ctx Context) (int8, error) func github.com/apache/thrift/lib/go/thrift.(*TCompactProtocol).ReadDouble(ctx Context) (value float64, err error) func github.com/apache/thrift/lib/go/thrift.(*TCompactProtocol).ReadFieldBegin(ctx Context) (name string, typeId thrift.TType, id int16, err error) func github.com/apache/thrift/lib/go/thrift.(*TCompactProtocol).ReadFieldEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TCompactProtocol).ReadI16(ctx Context) (value int16, err error) func github.com/apache/thrift/lib/go/thrift.(*TCompactProtocol).ReadI32(ctx Context) (value int32, err error) func github.com/apache/thrift/lib/go/thrift.(*TCompactProtocol).ReadI64(ctx Context) (value int64, err error) func github.com/apache/thrift/lib/go/thrift.(*TCompactProtocol).ReadListBegin(ctx Context) (elemType thrift.TType, size int, err error) func github.com/apache/thrift/lib/go/thrift.(*TCompactProtocol).ReadListEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TCompactProtocol).ReadMapBegin(ctx Context) (keyType thrift.TType, valueType thrift.TType, size int, err error) func github.com/apache/thrift/lib/go/thrift.(*TCompactProtocol).ReadMapEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TCompactProtocol).ReadMessageBegin(ctx Context) (name string, typeId thrift.TMessageType, seqId int32, err error) func github.com/apache/thrift/lib/go/thrift.(*TCompactProtocol).ReadMessageEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TCompactProtocol).ReadSetBegin(ctx Context) (elemType thrift.TType, size int, err error) func github.com/apache/thrift/lib/go/thrift.(*TCompactProtocol).ReadSetEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TCompactProtocol).ReadString(ctx Context) (value string, err error) func github.com/apache/thrift/lib/go/thrift.(*TCompactProtocol).ReadStructBegin(ctx Context) (name string, err error) func github.com/apache/thrift/lib/go/thrift.(*TCompactProtocol).ReadStructEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TCompactProtocol).ReadUUID(ctx Context) (value thrift.Tuuid, err error) func github.com/apache/thrift/lib/go/thrift.(*TCompactProtocol).Skip(ctx Context, fieldType thrift.TType) (err error) func github.com/apache/thrift/lib/go/thrift.(*TCompactProtocol).WriteBinary(ctx Context, bin []byte) error func github.com/apache/thrift/lib/go/thrift.(*TCompactProtocol).WriteBool(ctx Context, value bool) error func github.com/apache/thrift/lib/go/thrift.(*TCompactProtocol).WriteByte(ctx Context, value int8) error func github.com/apache/thrift/lib/go/thrift.(*TCompactProtocol).WriteDouble(ctx Context, value float64) error func github.com/apache/thrift/lib/go/thrift.(*TCompactProtocol).WriteFieldBegin(ctx Context, name string, typeId thrift.TType, id int16) error func github.com/apache/thrift/lib/go/thrift.(*TCompactProtocol).WriteFieldEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TCompactProtocol).WriteFieldStop(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TCompactProtocol).WriteI16(ctx Context, value int16) error func github.com/apache/thrift/lib/go/thrift.(*TCompactProtocol).WriteI32(ctx Context, value int32) error func github.com/apache/thrift/lib/go/thrift.(*TCompactProtocol).WriteI64(ctx Context, value int64) error func github.com/apache/thrift/lib/go/thrift.(*TCompactProtocol).WriteListBegin(ctx Context, elemType thrift.TType, size int) error func github.com/apache/thrift/lib/go/thrift.(*TCompactProtocol).WriteListEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TCompactProtocol).WriteMapBegin(ctx Context, keyType thrift.TType, valueType thrift.TType, size int) error func github.com/apache/thrift/lib/go/thrift.(*TCompactProtocol).WriteMapEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TCompactProtocol).WriteMessageBegin(ctx Context, name string, typeId thrift.TMessageType, seqid int32) error func github.com/apache/thrift/lib/go/thrift.(*TCompactProtocol).WriteMessageEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TCompactProtocol).WriteSetBegin(ctx Context, elemType thrift.TType, size int) error func github.com/apache/thrift/lib/go/thrift.(*TCompactProtocol).WriteSetEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TCompactProtocol).WriteString(ctx Context, value string) error func github.com/apache/thrift/lib/go/thrift.(*TCompactProtocol).WriteStructBegin(ctx Context, name string) error func github.com/apache/thrift/lib/go/thrift.(*TCompactProtocol).WriteStructEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TCompactProtocol).WriteUUID(ctx Context, value thrift.Tuuid) error func github.com/apache/thrift/lib/go/thrift.(*TDebugProtocol).Flush(ctx Context) (err error) func github.com/apache/thrift/lib/go/thrift.(*TDebugProtocol).ReadBinary(ctx Context) (value []byte, err error) func github.com/apache/thrift/lib/go/thrift.(*TDebugProtocol).ReadBool(ctx Context) (value bool, err error) func github.com/apache/thrift/lib/go/thrift.(*TDebugProtocol).ReadByte(ctx Context) (value int8, err error) func github.com/apache/thrift/lib/go/thrift.(*TDebugProtocol).ReadDouble(ctx Context) (value float64, err error) func github.com/apache/thrift/lib/go/thrift.(*TDebugProtocol).ReadFieldBegin(ctx Context) (name string, typeId thrift.TType, id int16, err error) func github.com/apache/thrift/lib/go/thrift.(*TDebugProtocol).ReadFieldEnd(ctx Context) (err error) func github.com/apache/thrift/lib/go/thrift.(*TDebugProtocol).ReadI16(ctx Context) (value int16, err error) func github.com/apache/thrift/lib/go/thrift.(*TDebugProtocol).ReadI32(ctx Context) (value int32, err error) func github.com/apache/thrift/lib/go/thrift.(*TDebugProtocol).ReadI64(ctx Context) (value int64, err error) func github.com/apache/thrift/lib/go/thrift.(*TDebugProtocol).ReadListBegin(ctx Context) (elemType thrift.TType, size int, err error) func github.com/apache/thrift/lib/go/thrift.(*TDebugProtocol).ReadListEnd(ctx Context) (err error) func github.com/apache/thrift/lib/go/thrift.(*TDebugProtocol).ReadMapBegin(ctx Context) (keyType thrift.TType, valueType thrift.TType, size int, err error) func github.com/apache/thrift/lib/go/thrift.(*TDebugProtocol).ReadMapEnd(ctx Context) (err error) func github.com/apache/thrift/lib/go/thrift.(*TDebugProtocol).ReadMessageBegin(ctx Context) (name string, typeId thrift.TMessageType, seqid int32, err error) func github.com/apache/thrift/lib/go/thrift.(*TDebugProtocol).ReadMessageEnd(ctx Context) (err error) func github.com/apache/thrift/lib/go/thrift.(*TDebugProtocol).ReadSetBegin(ctx Context) (elemType thrift.TType, size int, err error) func github.com/apache/thrift/lib/go/thrift.(*TDebugProtocol).ReadSetEnd(ctx Context) (err error) func github.com/apache/thrift/lib/go/thrift.(*TDebugProtocol).ReadString(ctx Context) (value string, err error) func github.com/apache/thrift/lib/go/thrift.(*TDebugProtocol).ReadStructBegin(ctx Context) (name string, err error) func github.com/apache/thrift/lib/go/thrift.(*TDebugProtocol).ReadStructEnd(ctx Context) (err error) func github.com/apache/thrift/lib/go/thrift.(*TDebugProtocol).ReadUUID(ctx Context) (value thrift.Tuuid, err error) func github.com/apache/thrift/lib/go/thrift.(*TDebugProtocol).Skip(ctx Context, fieldType thrift.TType) (err error) func github.com/apache/thrift/lib/go/thrift.(*TDebugProtocol).WriteBinary(ctx Context, value []byte) error func github.com/apache/thrift/lib/go/thrift.(*TDebugProtocol).WriteBool(ctx Context, value bool) error func github.com/apache/thrift/lib/go/thrift.(*TDebugProtocol).WriteByte(ctx Context, value int8) error func github.com/apache/thrift/lib/go/thrift.(*TDebugProtocol).WriteDouble(ctx Context, value float64) error func github.com/apache/thrift/lib/go/thrift.(*TDebugProtocol).WriteFieldBegin(ctx Context, name string, typeId thrift.TType, id int16) error func github.com/apache/thrift/lib/go/thrift.(*TDebugProtocol).WriteFieldEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TDebugProtocol).WriteFieldStop(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TDebugProtocol).WriteI16(ctx Context, value int16) error func github.com/apache/thrift/lib/go/thrift.(*TDebugProtocol).WriteI32(ctx Context, value int32) error func github.com/apache/thrift/lib/go/thrift.(*TDebugProtocol).WriteI64(ctx Context, value int64) error func github.com/apache/thrift/lib/go/thrift.(*TDebugProtocol).WriteListBegin(ctx Context, elemType thrift.TType, size int) error func github.com/apache/thrift/lib/go/thrift.(*TDebugProtocol).WriteListEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TDebugProtocol).WriteMapBegin(ctx Context, keyType thrift.TType, valueType thrift.TType, size int) error func github.com/apache/thrift/lib/go/thrift.(*TDebugProtocol).WriteMapEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TDebugProtocol).WriteMessageBegin(ctx Context, name string, typeId thrift.TMessageType, seqid int32) error func github.com/apache/thrift/lib/go/thrift.(*TDebugProtocol).WriteMessageEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TDebugProtocol).WriteSetBegin(ctx Context, elemType thrift.TType, size int) error func github.com/apache/thrift/lib/go/thrift.(*TDebugProtocol).WriteSetEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TDebugProtocol).WriteString(ctx Context, value string) error func github.com/apache/thrift/lib/go/thrift.(*TDebugProtocol).WriteStructBegin(ctx Context, name string) error func github.com/apache/thrift/lib/go/thrift.(*TDebugProtocol).WriteStructEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TDebugProtocol).WriteUUID(ctx Context, value thrift.Tuuid) error func github.com/apache/thrift/lib/go/thrift.(*TDeserializer).Read(ctx Context, msg thrift.TStruct, b []byte) (err error) func github.com/apache/thrift/lib/go/thrift.(*TDeserializer).ReadString(ctx Context, msg thrift.TStruct, s string) (err error) func github.com/apache/thrift/lib/go/thrift.(*TDeserializerPool).Read(ctx Context, msg thrift.TStruct, b []byte) error func github.com/apache/thrift/lib/go/thrift.(*TDeserializerPool).ReadString(ctx Context, msg thrift.TStruct, s string) error func github.com/apache/thrift/lib/go/thrift.(*TDuplicateToProtocol).Flush(ctx Context) (err error) func github.com/apache/thrift/lib/go/thrift.(*TDuplicateToProtocol).ReadBinary(ctx Context) (value []byte, err error) func github.com/apache/thrift/lib/go/thrift.(*TDuplicateToProtocol).ReadBool(ctx Context) (value bool, err error) func github.com/apache/thrift/lib/go/thrift.(*TDuplicateToProtocol).ReadByte(ctx Context) (value int8, err error) func github.com/apache/thrift/lib/go/thrift.(*TDuplicateToProtocol).ReadDouble(ctx Context) (value float64, err error) func github.com/apache/thrift/lib/go/thrift.(*TDuplicateToProtocol).ReadFieldBegin(ctx Context) (name string, typeId thrift.TType, id int16, err error) func github.com/apache/thrift/lib/go/thrift.(*TDuplicateToProtocol).ReadFieldEnd(ctx Context) (err error) func github.com/apache/thrift/lib/go/thrift.(*TDuplicateToProtocol).ReadI16(ctx Context) (value int16, err error) func github.com/apache/thrift/lib/go/thrift.(*TDuplicateToProtocol).ReadI32(ctx Context) (value int32, err error) func github.com/apache/thrift/lib/go/thrift.(*TDuplicateToProtocol).ReadI64(ctx Context) (value int64, err error) func github.com/apache/thrift/lib/go/thrift.(*TDuplicateToProtocol).ReadListBegin(ctx Context) (elemType thrift.TType, size int, err error) func github.com/apache/thrift/lib/go/thrift.(*TDuplicateToProtocol).ReadListEnd(ctx Context) (err error) func github.com/apache/thrift/lib/go/thrift.(*TDuplicateToProtocol).ReadMapBegin(ctx Context) (keyType thrift.TType, valueType thrift.TType, size int, err error) func github.com/apache/thrift/lib/go/thrift.(*TDuplicateToProtocol).ReadMapEnd(ctx Context) (err error) func github.com/apache/thrift/lib/go/thrift.(*TDuplicateToProtocol).ReadMessageBegin(ctx Context) (name string, typeId thrift.TMessageType, seqid int32, err error) func github.com/apache/thrift/lib/go/thrift.(*TDuplicateToProtocol).ReadMessageEnd(ctx Context) (err error) func github.com/apache/thrift/lib/go/thrift.(*TDuplicateToProtocol).ReadSetBegin(ctx Context) (elemType thrift.TType, size int, err error) func github.com/apache/thrift/lib/go/thrift.(*TDuplicateToProtocol).ReadSetEnd(ctx Context) (err error) func github.com/apache/thrift/lib/go/thrift.(*TDuplicateToProtocol).ReadString(ctx Context) (value string, err error) func github.com/apache/thrift/lib/go/thrift.(*TDuplicateToProtocol).ReadStructBegin(ctx Context) (name string, err error) func github.com/apache/thrift/lib/go/thrift.(*TDuplicateToProtocol).ReadStructEnd(ctx Context) (err error) func github.com/apache/thrift/lib/go/thrift.(*TDuplicateToProtocol).ReadUUID(ctx Context) (value thrift.Tuuid, err error) func github.com/apache/thrift/lib/go/thrift.(*TDuplicateToProtocol).Skip(ctx Context, fieldType thrift.TType) (err error) func github.com/apache/thrift/lib/go/thrift.(*TDuplicateToProtocol).WriteBinary(ctx Context, value []byte) error func github.com/apache/thrift/lib/go/thrift.(*TDuplicateToProtocol).WriteBool(ctx Context, value bool) error func github.com/apache/thrift/lib/go/thrift.(*TDuplicateToProtocol).WriteByte(ctx Context, value int8) error func github.com/apache/thrift/lib/go/thrift.(*TDuplicateToProtocol).WriteDouble(ctx Context, value float64) error func github.com/apache/thrift/lib/go/thrift.(*TDuplicateToProtocol).WriteFieldBegin(ctx Context, name string, typeId thrift.TType, id int16) error func github.com/apache/thrift/lib/go/thrift.(*TDuplicateToProtocol).WriteFieldEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TDuplicateToProtocol).WriteFieldStop(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TDuplicateToProtocol).WriteI16(ctx Context, value int16) error func github.com/apache/thrift/lib/go/thrift.(*TDuplicateToProtocol).WriteI32(ctx Context, value int32) error func github.com/apache/thrift/lib/go/thrift.(*TDuplicateToProtocol).WriteI64(ctx Context, value int64) error func github.com/apache/thrift/lib/go/thrift.(*TDuplicateToProtocol).WriteListBegin(ctx Context, elemType thrift.TType, size int) error func github.com/apache/thrift/lib/go/thrift.(*TDuplicateToProtocol).WriteListEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TDuplicateToProtocol).WriteMapBegin(ctx Context, keyType thrift.TType, valueType thrift.TType, size int) error func github.com/apache/thrift/lib/go/thrift.(*TDuplicateToProtocol).WriteMapEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TDuplicateToProtocol).WriteMessageBegin(ctx Context, name string, typeId thrift.TMessageType, seqid int32) error func github.com/apache/thrift/lib/go/thrift.(*TDuplicateToProtocol).WriteMessageEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TDuplicateToProtocol).WriteSetBegin(ctx Context, elemType thrift.TType, size int) error func github.com/apache/thrift/lib/go/thrift.(*TDuplicateToProtocol).WriteSetEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TDuplicateToProtocol).WriteString(ctx Context, value string) error func github.com/apache/thrift/lib/go/thrift.(*TDuplicateToProtocol).WriteStructBegin(ctx Context, name string) error func github.com/apache/thrift/lib/go/thrift.(*TDuplicateToProtocol).WriteStructEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TDuplicateToProtocol).WriteUUID(ctx Context, value thrift.Tuuid) error func github.com/apache/thrift/lib/go/thrift.(*TFramedTransport).Flush(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*THeaderProtocol).Flush(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*THeaderProtocol).ReadBinary(ctx Context) (value []byte, err error) func github.com/apache/thrift/lib/go/thrift.(*THeaderProtocol).ReadBool(ctx Context) (value bool, err error) func github.com/apache/thrift/lib/go/thrift.(*THeaderProtocol).ReadByte(ctx Context) (value int8, err error) func github.com/apache/thrift/lib/go/thrift.(*THeaderProtocol).ReadDouble(ctx Context) (value float64, err error) func github.com/apache/thrift/lib/go/thrift.(*THeaderProtocol).ReadFieldBegin(ctx Context) (name string, typeID thrift.TType, id int16, err error) func github.com/apache/thrift/lib/go/thrift.(*THeaderProtocol).ReadFieldEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*THeaderProtocol).ReadFrame(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*THeaderProtocol).ReadI16(ctx Context) (value int16, err error) func github.com/apache/thrift/lib/go/thrift.(*THeaderProtocol).ReadI32(ctx Context) (value int32, err error) func github.com/apache/thrift/lib/go/thrift.(*THeaderProtocol).ReadI64(ctx Context) (value int64, err error) func github.com/apache/thrift/lib/go/thrift.(*THeaderProtocol).ReadListBegin(ctx Context) (elemType thrift.TType, size int, err error) func github.com/apache/thrift/lib/go/thrift.(*THeaderProtocol).ReadListEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*THeaderProtocol).ReadMapBegin(ctx Context) (keyType thrift.TType, valueType thrift.TType, size int, err error) func github.com/apache/thrift/lib/go/thrift.(*THeaderProtocol).ReadMapEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*THeaderProtocol).ReadMessageBegin(ctx Context) (name string, typeID thrift.TMessageType, seqID int32, err error) func github.com/apache/thrift/lib/go/thrift.(*THeaderProtocol).ReadMessageEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*THeaderProtocol).ReadSetBegin(ctx Context) (elemType thrift.TType, size int, err error) func github.com/apache/thrift/lib/go/thrift.(*THeaderProtocol).ReadSetEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*THeaderProtocol).ReadString(ctx Context) (value string, err error) func github.com/apache/thrift/lib/go/thrift.(*THeaderProtocol).ReadStructBegin(ctx Context) (name string, err error) func github.com/apache/thrift/lib/go/thrift.(*THeaderProtocol).ReadStructEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*THeaderProtocol).ReadUUID(ctx Context) (value thrift.Tuuid, err error) func github.com/apache/thrift/lib/go/thrift.(*THeaderProtocol).Skip(ctx Context, fieldType thrift.TType) error func github.com/apache/thrift/lib/go/thrift.(*THeaderProtocol).WriteBinary(ctx Context, value []byte) error func github.com/apache/thrift/lib/go/thrift.(*THeaderProtocol).WriteBool(ctx Context, value bool) error func github.com/apache/thrift/lib/go/thrift.(*THeaderProtocol).WriteByte(ctx Context, value int8) error func github.com/apache/thrift/lib/go/thrift.(*THeaderProtocol).WriteDouble(ctx Context, value float64) error func github.com/apache/thrift/lib/go/thrift.(*THeaderProtocol).WriteFieldBegin(ctx Context, name string, typeID thrift.TType, id int16) error func github.com/apache/thrift/lib/go/thrift.(*THeaderProtocol).WriteFieldEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*THeaderProtocol).WriteFieldStop(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*THeaderProtocol).WriteI16(ctx Context, value int16) error func github.com/apache/thrift/lib/go/thrift.(*THeaderProtocol).WriteI32(ctx Context, value int32) error func github.com/apache/thrift/lib/go/thrift.(*THeaderProtocol).WriteI64(ctx Context, value int64) error func github.com/apache/thrift/lib/go/thrift.(*THeaderProtocol).WriteListBegin(ctx Context, elemType thrift.TType, size int) error func github.com/apache/thrift/lib/go/thrift.(*THeaderProtocol).WriteListEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*THeaderProtocol).WriteMapBegin(ctx Context, keyType thrift.TType, valueType thrift.TType, size int) error func github.com/apache/thrift/lib/go/thrift.(*THeaderProtocol).WriteMapEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*THeaderProtocol).WriteMessageBegin(ctx Context, name string, typeID thrift.TMessageType, seqID int32) error func github.com/apache/thrift/lib/go/thrift.(*THeaderProtocol).WriteMessageEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*THeaderProtocol).WriteSetBegin(ctx Context, elemType thrift.TType, size int) error func github.com/apache/thrift/lib/go/thrift.(*THeaderProtocol).WriteSetEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*THeaderProtocol).WriteString(ctx Context, value string) error func github.com/apache/thrift/lib/go/thrift.(*THeaderProtocol).WriteStructBegin(ctx Context, name string) error func github.com/apache/thrift/lib/go/thrift.(*THeaderProtocol).WriteStructEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*THeaderProtocol).WriteUUID(ctx Context, value thrift.Tuuid) error func github.com/apache/thrift/lib/go/thrift.(*THeaderTransport).Flush(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*THeaderTransport).ReadFrame(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*THttpClient).Flush(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TJSONProtocol).Flush(ctx Context) (err error) func github.com/apache/thrift/lib/go/thrift.(*TJSONProtocol).ReadBinary(ctx Context) ([]byte, error) func github.com/apache/thrift/lib/go/thrift.(*TJSONProtocol).ReadBool(ctx Context) (bool, error) func github.com/apache/thrift/lib/go/thrift.(*TJSONProtocol).ReadByte(ctx Context) (int8, error) func github.com/apache/thrift/lib/go/thrift.(*TJSONProtocol).ReadDouble(ctx Context) (float64, error) func github.com/apache/thrift/lib/go/thrift.(*TJSONProtocol).ReadFieldBegin(ctx Context) (string, thrift.TType, int16, error) func github.com/apache/thrift/lib/go/thrift.(*TJSONProtocol).ReadFieldEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TJSONProtocol).ReadI16(ctx Context) (int16, error) func github.com/apache/thrift/lib/go/thrift.(*TJSONProtocol).ReadI32(ctx Context) (int32, error) func github.com/apache/thrift/lib/go/thrift.(*TJSONProtocol).ReadI64(ctx Context) (int64, error) func github.com/apache/thrift/lib/go/thrift.(*TJSONProtocol).ReadListBegin(ctx Context) (elemType thrift.TType, size int, e error) func github.com/apache/thrift/lib/go/thrift.(*TJSONProtocol).ReadListEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TJSONProtocol).ReadMapBegin(ctx Context) (keyType thrift.TType, valueType thrift.TType, size int, e error) func github.com/apache/thrift/lib/go/thrift.(*TJSONProtocol).ReadMapEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TJSONProtocol).ReadMessageBegin(ctx Context) (name string, typeId thrift.TMessageType, seqId int32, err error) func github.com/apache/thrift/lib/go/thrift.(*TJSONProtocol).ReadMessageEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TJSONProtocol).ReadSetBegin(ctx Context) (elemType thrift.TType, size int, e error) func github.com/apache/thrift/lib/go/thrift.(*TJSONProtocol).ReadSetEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TJSONProtocol).ReadString(ctx Context) (string, error) func github.com/apache/thrift/lib/go/thrift.(*TJSONProtocol).ReadStructBegin(ctx Context) (name string, err error) func github.com/apache/thrift/lib/go/thrift.(*TJSONProtocol).ReadStructEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TJSONProtocol).Skip(ctx Context, fieldType thrift.TType) (err error) func github.com/apache/thrift/lib/go/thrift.(*TJSONProtocol).WriteBinary(ctx Context, v []byte) error func github.com/apache/thrift/lib/go/thrift.(*TJSONProtocol).WriteBool(ctx Context, b bool) error func github.com/apache/thrift/lib/go/thrift.(*TJSONProtocol).WriteByte(ctx Context, b int8) error func github.com/apache/thrift/lib/go/thrift.(*TJSONProtocol).WriteDouble(ctx Context, v float64) error func github.com/apache/thrift/lib/go/thrift.(*TJSONProtocol).WriteFieldBegin(ctx Context, name string, typeId thrift.TType, id int16) error func github.com/apache/thrift/lib/go/thrift.(*TJSONProtocol).WriteFieldEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TJSONProtocol).WriteFieldStop(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TJSONProtocol).WriteI16(ctx Context, v int16) error func github.com/apache/thrift/lib/go/thrift.(*TJSONProtocol).WriteI32(ctx Context, v int32) error func github.com/apache/thrift/lib/go/thrift.(*TJSONProtocol).WriteI64(ctx Context, v int64) error func github.com/apache/thrift/lib/go/thrift.(*TJSONProtocol).WriteListBegin(ctx Context, elemType thrift.TType, size int) error func github.com/apache/thrift/lib/go/thrift.(*TJSONProtocol).WriteListEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TJSONProtocol).WriteMapBegin(ctx Context, keyType thrift.TType, valueType thrift.TType, size int) error func github.com/apache/thrift/lib/go/thrift.(*TJSONProtocol).WriteMapEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TJSONProtocol).WriteMessageBegin(ctx Context, name string, typeId thrift.TMessageType, seqId int32) error func github.com/apache/thrift/lib/go/thrift.(*TJSONProtocol).WriteMessageEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TJSONProtocol).WriteSetBegin(ctx Context, elemType thrift.TType, size int) error func github.com/apache/thrift/lib/go/thrift.(*TJSONProtocol).WriteSetEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TJSONProtocol).WriteString(ctx Context, v string) error func github.com/apache/thrift/lib/go/thrift.(*TJSONProtocol).WriteStructBegin(ctx Context, name string) error func github.com/apache/thrift/lib/go/thrift.(*TJSONProtocol).WriteStructEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TMemoryBuffer).Flush(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TMultiplexedProcessor).Process(ctx Context, in, out thrift.TProtocol) (bool, thrift.TException) func github.com/apache/thrift/lib/go/thrift.(*TMultiplexedProtocol).WriteMessageBegin(ctx Context, name string, typeId thrift.TMessageType, seqid int32) error func github.com/apache/thrift/lib/go/thrift.TProcessor.Process(ctx Context, in, out thrift.TProtocol) (bool, thrift.TException) func github.com/apache/thrift/lib/go/thrift.TProcessorFunction.Process(ctx Context, seqId int32, in, out thrift.TProtocol) (bool, thrift.TException) func github.com/apache/thrift/lib/go/thrift.TProtocol.Flush(ctx Context) (err error) func github.com/apache/thrift/lib/go/thrift.TProtocol.ReadBinary(ctx Context) (value []byte, err error) func github.com/apache/thrift/lib/go/thrift.TProtocol.ReadBool(ctx Context) (value bool, err error) func github.com/apache/thrift/lib/go/thrift.TProtocol.ReadByte(ctx Context) (value int8, err error) func github.com/apache/thrift/lib/go/thrift.TProtocol.ReadDouble(ctx Context) (value float64, err error) func github.com/apache/thrift/lib/go/thrift.TProtocol.ReadFieldBegin(ctx Context) (name string, typeId thrift.TType, id int16, err error) func github.com/apache/thrift/lib/go/thrift.TProtocol.ReadFieldEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.TProtocol.ReadI16(ctx Context) (value int16, err error) func github.com/apache/thrift/lib/go/thrift.TProtocol.ReadI32(ctx Context) (value int32, err error) func github.com/apache/thrift/lib/go/thrift.TProtocol.ReadI64(ctx Context) (value int64, err error) func github.com/apache/thrift/lib/go/thrift.TProtocol.ReadListBegin(ctx Context) (elemType thrift.TType, size int, err error) func github.com/apache/thrift/lib/go/thrift.TProtocol.ReadListEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.TProtocol.ReadMapBegin(ctx Context) (keyType thrift.TType, valueType thrift.TType, size int, err error) func github.com/apache/thrift/lib/go/thrift.TProtocol.ReadMapEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.TProtocol.ReadMessageBegin(ctx Context) (name string, typeId thrift.TMessageType, seqid int32, err error) func github.com/apache/thrift/lib/go/thrift.TProtocol.ReadMessageEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.TProtocol.ReadSetBegin(ctx Context) (elemType thrift.TType, size int, err error) func github.com/apache/thrift/lib/go/thrift.TProtocol.ReadSetEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.TProtocol.ReadString(ctx Context) (value string, err error) func github.com/apache/thrift/lib/go/thrift.TProtocol.ReadStructBegin(ctx Context) (name string, err error) func github.com/apache/thrift/lib/go/thrift.TProtocol.ReadStructEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.TProtocol.ReadUUID(ctx Context) (value thrift.Tuuid, err error) func github.com/apache/thrift/lib/go/thrift.TProtocol.Skip(ctx Context, fieldType thrift.TType) (err error) func github.com/apache/thrift/lib/go/thrift.TProtocol.WriteBinary(ctx Context, value []byte) error func github.com/apache/thrift/lib/go/thrift.TProtocol.WriteBool(ctx Context, value bool) error func github.com/apache/thrift/lib/go/thrift.TProtocol.WriteByte(ctx Context, value int8) error func github.com/apache/thrift/lib/go/thrift.TProtocol.WriteDouble(ctx Context, value float64) error func github.com/apache/thrift/lib/go/thrift.TProtocol.WriteFieldBegin(ctx Context, name string, typeId thrift.TType, id int16) error func github.com/apache/thrift/lib/go/thrift.TProtocol.WriteFieldEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.TProtocol.WriteFieldStop(ctx Context) error func github.com/apache/thrift/lib/go/thrift.TProtocol.WriteI16(ctx Context, value int16) error func github.com/apache/thrift/lib/go/thrift.TProtocol.WriteI32(ctx Context, value int32) error func github.com/apache/thrift/lib/go/thrift.TProtocol.WriteI64(ctx Context, value int64) error func github.com/apache/thrift/lib/go/thrift.TProtocol.WriteListBegin(ctx Context, elemType thrift.TType, size int) error func github.com/apache/thrift/lib/go/thrift.TProtocol.WriteListEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.TProtocol.WriteMapBegin(ctx Context, keyType thrift.TType, valueType thrift.TType, size int) error func github.com/apache/thrift/lib/go/thrift.TProtocol.WriteMapEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.TProtocol.WriteMessageBegin(ctx Context, name string, typeId thrift.TMessageType, seqid int32) error func github.com/apache/thrift/lib/go/thrift.TProtocol.WriteMessageEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.TProtocol.WriteSetBegin(ctx Context, elemType thrift.TType, size int) error func github.com/apache/thrift/lib/go/thrift.TProtocol.WriteSetEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.TProtocol.WriteString(ctx Context, value string) error func github.com/apache/thrift/lib/go/thrift.TProtocol.WriteStructBegin(ctx Context, name string) error func github.com/apache/thrift/lib/go/thrift.TProtocol.WriteStructEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.TProtocol.WriteUUID(ctx Context, value thrift.Tuuid) error func github.com/apache/thrift/lib/go/thrift.TRichTransport.Flush(ctx Context) (err error) func github.com/apache/thrift/lib/go/thrift.(*TSerializer).Write(ctx Context, msg thrift.TStruct) (b []byte, err error) func github.com/apache/thrift/lib/go/thrift.(*TSerializer).WriteString(ctx Context, msg thrift.TStruct) (s string, err error) func github.com/apache/thrift/lib/go/thrift.(*TSerializerPool).Write(ctx Context, msg thrift.TStruct) ([]byte, error) func github.com/apache/thrift/lib/go/thrift.(*TSerializerPool).WriteString(ctx Context, msg thrift.TStruct) (string, error) func github.com/apache/thrift/lib/go/thrift.(*TSimpleJSONProtocol).Flush(ctx Context) (err error) func github.com/apache/thrift/lib/go/thrift.(*TSimpleJSONProtocol).ReadBinary(ctx Context) ([]byte, error) func github.com/apache/thrift/lib/go/thrift.(*TSimpleJSONProtocol).ReadBool(ctx Context) (bool, error) func github.com/apache/thrift/lib/go/thrift.(*TSimpleJSONProtocol).ReadByte(ctx Context) (int8, error) func github.com/apache/thrift/lib/go/thrift.(*TSimpleJSONProtocol).ReadDouble(ctx Context) (float64, error) func github.com/apache/thrift/lib/go/thrift.(*TSimpleJSONProtocol).ReadFieldBegin(ctx Context) (string, thrift.TType, int16, error) func github.com/apache/thrift/lib/go/thrift.(*TSimpleJSONProtocol).ReadFieldEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TSimpleJSONProtocol).ReadI16(ctx Context) (int16, error) func github.com/apache/thrift/lib/go/thrift.(*TSimpleJSONProtocol).ReadI32(ctx Context) (int32, error) func github.com/apache/thrift/lib/go/thrift.(*TSimpleJSONProtocol).ReadI64(ctx Context) (int64, error) func github.com/apache/thrift/lib/go/thrift.(*TSimpleJSONProtocol).ReadListBegin(ctx Context) (elemType thrift.TType, size int, e error) func github.com/apache/thrift/lib/go/thrift.(*TSimpleJSONProtocol).ReadListEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TSimpleJSONProtocol).ReadMapBegin(ctx Context) (keyType thrift.TType, valueType thrift.TType, size int, e error) func github.com/apache/thrift/lib/go/thrift.(*TSimpleJSONProtocol).ReadMapEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TSimpleJSONProtocol).ReadMessageBegin(ctx Context) (name string, typeId thrift.TMessageType, seqId int32, err error) func github.com/apache/thrift/lib/go/thrift.(*TSimpleJSONProtocol).ReadMessageEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TSimpleJSONProtocol).ReadSetBegin(ctx Context) (elemType thrift.TType, size int, e error) func github.com/apache/thrift/lib/go/thrift.(*TSimpleJSONProtocol).ReadSetEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TSimpleJSONProtocol).ReadString(ctx Context) (string, error) func github.com/apache/thrift/lib/go/thrift.(*TSimpleJSONProtocol).ReadStructBegin(ctx Context) (name string, err error) func github.com/apache/thrift/lib/go/thrift.(*TSimpleJSONProtocol).ReadStructEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TSimpleJSONProtocol).ReadUUID(ctx Context) (v thrift.Tuuid, err error) func github.com/apache/thrift/lib/go/thrift.(*TSimpleJSONProtocol).Skip(ctx Context, fieldType thrift.TType) (err error) func github.com/apache/thrift/lib/go/thrift.(*TSimpleJSONProtocol).WriteBinary(ctx Context, v []byte) error func github.com/apache/thrift/lib/go/thrift.(*TSimpleJSONProtocol).WriteBool(ctx Context, b bool) error func github.com/apache/thrift/lib/go/thrift.(*TSimpleJSONProtocol).WriteByte(ctx Context, b int8) error func github.com/apache/thrift/lib/go/thrift.(*TSimpleJSONProtocol).WriteDouble(ctx Context, v float64) error func github.com/apache/thrift/lib/go/thrift.(*TSimpleJSONProtocol).WriteFieldBegin(ctx Context, name string, typeId thrift.TType, id int16) error func github.com/apache/thrift/lib/go/thrift.(*TSimpleJSONProtocol).WriteFieldEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TSimpleJSONProtocol).WriteFieldStop(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TSimpleJSONProtocol).WriteI16(ctx Context, v int16) error func github.com/apache/thrift/lib/go/thrift.(*TSimpleJSONProtocol).WriteI32(ctx Context, v int32) error func github.com/apache/thrift/lib/go/thrift.(*TSimpleJSONProtocol).WriteI64(ctx Context, v int64) error func github.com/apache/thrift/lib/go/thrift.(*TSimpleJSONProtocol).WriteListBegin(ctx Context, elemType thrift.TType, size int) error func github.com/apache/thrift/lib/go/thrift.(*TSimpleJSONProtocol).WriteListEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TSimpleJSONProtocol).WriteMapBegin(ctx Context, keyType thrift.TType, valueType thrift.TType, size int) error func github.com/apache/thrift/lib/go/thrift.(*TSimpleJSONProtocol).WriteMapEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TSimpleJSONProtocol).WriteMessageBegin(ctx Context, name string, typeId thrift.TMessageType, seqId int32) error func github.com/apache/thrift/lib/go/thrift.(*TSimpleJSONProtocol).WriteMessageEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TSimpleJSONProtocol).WriteSetBegin(ctx Context, elemType thrift.TType, size int) error func github.com/apache/thrift/lib/go/thrift.(*TSimpleJSONProtocol).WriteSetEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TSimpleJSONProtocol).WriteString(ctx Context, v string) error func github.com/apache/thrift/lib/go/thrift.(*TSimpleJSONProtocol).WriteStructBegin(ctx Context, name string) error func github.com/apache/thrift/lib/go/thrift.(*TSimpleJSONProtocol).WriteStructEnd(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TSimpleJSONProtocol).WriteUUID(ctx Context, v thrift.Tuuid) error func github.com/apache/thrift/lib/go/thrift.(*TSimpleServer).SetLogContext(ctx Context) func github.com/apache/thrift/lib/go/thrift.(*TSocket).Flush(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TSSLSocket).Flush(ctx Context) error func github.com/apache/thrift/lib/go/thrift.(*TStandardClient).Call(ctx Context, method string, args, result thrift.TStruct) (thrift.ResponseMeta, error) func github.com/apache/thrift/lib/go/thrift.(*TStandardClient).Recv(ctx Context, iprot thrift.TProtocol, seqId int32, method string, result thrift.TStruct) error func github.com/apache/thrift/lib/go/thrift.(*TStandardClient).Send(ctx Context, oprot thrift.TProtocol, seqId int32, method string, args thrift.TStruct) error func github.com/apache/thrift/lib/go/thrift.TStruct.Read(ctx Context, p thrift.TProtocol) error func github.com/apache/thrift/lib/go/thrift.TStruct.Write(ctx Context, p thrift.TProtocol) error func github.com/apache/thrift/lib/go/thrift.TTransport.Flush(ctx Context) (err error) func github.com/apache/thrift/lib/go/thrift.(*TZlibTransport).Flush(ctx Context) error func github.com/apache/thrift/lib/go/thrift.WrappedTClient.Call(ctx Context, method string, args, result thrift.TStruct) (thrift.ResponseMeta, error) func github.com/apache/thrift/lib/go/thrift.WrappedTProcessorFunction.Process(ctx Context, seqID int32, in, out thrift.TProtocol) (bool, thrift.TException) func github.com/benbjohnson/clock.Clock.WithDeadline(parent Context, d time.Time) (Context, CancelFunc) func github.com/benbjohnson/clock.Clock.WithTimeout(parent Context, t time.Duration) (Context, CancelFunc) func github.com/benbjohnson/clock.(*Mock).WithDeadline(parent Context, deadline time.Time) (Context, CancelFunc) func github.com/benbjohnson/clock.(*Mock).WithTimeout(parent Context, timeout time.Duration) (Context, CancelFunc) func github.com/cenkalti/backoff/v5.Retry[T](ctx Context, operation backoff.Operation[T], opts ...backoff.RetryOption) (T, error) func github.com/cenkalti/rpc2.(*Client).CallWithContext(ctx Context, method string, args interface{}, reply interface{}) error func github.com/chromedp/cdproto/accessibility.(*DisableParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/accessibility.(*EnableParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/accessibility.(*GetAXNodeAndAncestorsParams).Do(ctx Context) (nodes []*accessibility.Node, err error) func github.com/chromedp/cdproto/accessibility.(*GetChildAXNodesParams).Do(ctx Context) (nodes []*accessibility.Node, err error) func github.com/chromedp/cdproto/accessibility.(*GetFullAXTreeParams).Do(ctx Context) (nodes []*accessibility.Node, err error) func github.com/chromedp/cdproto/accessibility.(*GetPartialAXTreeParams).Do(ctx Context) (nodes []*accessibility.Node, err error) func github.com/chromedp/cdproto/accessibility.(*GetRootAXNodeParams).Do(ctx Context) (node *accessibility.Node, err error) func github.com/chromedp/cdproto/accessibility.(*QueryAXTreeParams).Do(ctx Context) (nodes []*accessibility.Node, err error) func github.com/chromedp/cdproto/animation.(*DisableParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/animation.(*EnableParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/animation.(*GetCurrentTimeParams).Do(ctx Context) (currentTime float64, err error) func github.com/chromedp/cdproto/animation.(*GetPlaybackRateParams).Do(ctx Context) (playbackRate float64, err error) func github.com/chromedp/cdproto/animation.(*ReleaseAnimationsParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/animation.(*ResolveAnimationParams).Do(ctx Context) (remoteObject *runtime.RemoteObject, err error) func github.com/chromedp/cdproto/animation.(*SeekAnimationsParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/animation.(*SetPausedParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/animation.(*SetPlaybackRateParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/animation.(*SetTimingParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/audits.(*CheckContrastParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/audits.(*CheckFormsIssuesParams).Do(ctx Context) (formIssues []*audits.GenericIssueDetails, err error) func github.com/chromedp/cdproto/audits.(*DisableParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/audits.(*EnableParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/audits.(*GetEncodedResponseParams).Do(ctx Context) (body []byte, originalSize int64, encodedSize int64, err error) func github.com/chromedp/cdproto/autofill.(*DisableParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/autofill.(*EnableParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/autofill.(*SetAddressesParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/autofill.(*TriggerParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/backgroundservice.(*ClearEventsParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/backgroundservice.(*SetRecordingParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/backgroundservice.(*StartObservingParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/backgroundservice.(*StopObservingParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/browser.(*AddPrivacySandboxEnrollmentOverrideParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/browser.(*CancelDownloadParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/browser.(*CloseParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/browser.(*CrashGpuProcessParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/browser.(*CrashParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/browser.(*ExecuteBrowserCommandParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/browser.(*GetBrowserCommandLineParams).Do(ctx Context) (arguments []string, err error) func github.com/chromedp/cdproto/browser.(*GetHistogramParams).Do(ctx Context) (histogram *browser.Histogram, err error) func github.com/chromedp/cdproto/browser.(*GetHistogramsParams).Do(ctx Context) (histograms []*browser.Histogram, err error) func github.com/chromedp/cdproto/browser.(*GetVersionParams).Do(ctx Context) (protocolVersion string, product string, revision string, userAgent string, jsVersion string, err error) func github.com/chromedp/cdproto/browser.(*GetWindowBoundsParams).Do(ctx Context) (bounds *browser.Bounds, err error) func github.com/chromedp/cdproto/browser.(*GetWindowForTargetParams).Do(ctx Context) (windowID browser.WindowID, bounds *browser.Bounds, err error) func github.com/chromedp/cdproto/browser.(*GrantPermissionsParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/browser.(*ResetPermissionsParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/browser.(*SetDockTileParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/browser.(*SetDownloadBehaviorParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/browser.(*SetPermissionParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/browser.(*SetWindowBoundsParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/cachestorage.(*DeleteCacheParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/cachestorage.(*DeleteEntryParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/cachestorage.(*RequestCachedResponseParams).Do(ctx Context) (response *cachestorage.CachedResponse, err error) func github.com/chromedp/cdproto/cachestorage.(*RequestCacheNamesParams).Do(ctx Context) (caches []*cachestorage.Cache, err error) func github.com/chromedp/cdproto/cachestorage.(*RequestEntriesParams).Do(ctx Context) (cacheDataEntries []*cachestorage.DataEntry, returnCount float64, err error) func github.com/chromedp/cdproto/cast.(*DisableParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/cast.(*EnableParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/cast.(*SetSinkToUseParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/cast.(*StartDesktopMirroringParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/cast.(*StartTabMirroringParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/cast.(*StopCastingParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/cdp.Execute(ctx Context, method string, params easyjson.Marshaler, res easyjson.Unmarshaler) error func github.com/chromedp/cdproto/cdp.ExecutorFromContext(ctx Context) cdp.Executor func github.com/chromedp/cdproto/cdp.WithExecutor(parent Context, executor cdp.Executor) Context func github.com/chromedp/cdproto/cdp.Executor.Execute(Context, string, easyjson.Marshaler, easyjson.Unmarshaler) error func github.com/chromedp/cdproto/css.(*AddRuleParams).Do(ctx Context) (rule *css.Rule, err error) func github.com/chromedp/cdproto/css.(*CollectClassNamesParams).Do(ctx Context) (classNames []string, err error) func github.com/chromedp/cdproto/css.(*CreateStyleSheetParams).Do(ctx Context) (styleSheetID css.StyleSheetID, err error) func github.com/chromedp/cdproto/css.(*DisableParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/css.(*EnableParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/css.(*ForcePseudoStateParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/css.(*GetBackgroundColorsParams).Do(ctx Context) (backgroundColors []string, computedFontSize string, computedFontWeight string, err error) func github.com/chromedp/cdproto/css.(*GetComputedStyleForNodeParams).Do(ctx Context) (computedStyle []*css.ComputedStyleProperty, err error) func github.com/chromedp/cdproto/css.(*GetInlineStylesForNodeParams).Do(ctx Context) (inlineStyle *css.Style, attributesStyle *css.Style, err error) func github.com/chromedp/cdproto/css.(*GetLayersForNodeParams).Do(ctx Context) (rootLayer *css.LayerData, err error) func github.com/chromedp/cdproto/css.(*GetMatchedStylesForNodeParams).Do(ctx Context) (inlineStyle *css.Style, attributesStyle *css.Style, matchedCSSRules []*css.RuleMatch, pseudoElements []*css.PseudoElementMatches, inherited []*css.InheritedStyleEntry, inheritedPseudoElements []*css.InheritedPseudoElementMatches, cssKeyframesRules []*css.KeyframesRule, cssPositionFallbackRules []*css.PositionFallbackRule, cssPropertyRules []*css.PropertyRule, cssPropertyRegistrations []*css.PropertyRegistration, parentLayoutNodeID cdp.NodeID, err error) func github.com/chromedp/cdproto/css.(*GetMediaQueriesParams).Do(ctx Context) (medias []*css.Media, err error) func github.com/chromedp/cdproto/css.(*GetPlatformFontsForNodeParams).Do(ctx Context) (fonts []*css.PlatformFontUsage, err error) func github.com/chromedp/cdproto/css.(*GetStyleSheetTextParams).Do(ctx Context) (text string, err error) func github.com/chromedp/cdproto/css.(*SetContainerQueryTextParams).Do(ctx Context) (containerQuery *css.ContainerQuery, err error) func github.com/chromedp/cdproto/css.(*SetEffectivePropertyValueForNodeParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/css.(*SetKeyframeKeyParams).Do(ctx Context) (keyText *css.Value, err error) func github.com/chromedp/cdproto/css.(*SetLocalFontsEnabledParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/css.(*SetMediaTextParams).Do(ctx Context) (media *css.Media, err error) func github.com/chromedp/cdproto/css.(*SetPropertyRulePropertyNameParams).Do(ctx Context) (propertyName *css.Value, err error) func github.com/chromedp/cdproto/css.(*SetRuleSelectorParams).Do(ctx Context) (selectorList *css.SelectorList, err error) func github.com/chromedp/cdproto/css.(*SetScopeTextParams).Do(ctx Context) (scope *css.Scope, err error) func github.com/chromedp/cdproto/css.(*SetStyleSheetTextParams).Do(ctx Context) (sourceMapURL string, err error) func github.com/chromedp/cdproto/css.(*SetStyleTextsParams).Do(ctx Context) (styles []*css.Style, err error) func github.com/chromedp/cdproto/css.(*SetSupportsTextParams).Do(ctx Context) (supports *css.Supports, err error) func github.com/chromedp/cdproto/css.(*StartRuleUsageTrackingParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/css.(*StopRuleUsageTrackingParams).Do(ctx Context) (ruleUsage []*css.RuleUsage, err error) func github.com/chromedp/cdproto/css.(*TakeComputedStyleUpdatesParams).Do(ctx Context) (nodeIDs []cdp.NodeID, err error) func github.com/chromedp/cdproto/css.(*TakeCoverageDeltaParams).Do(ctx Context) (coverage []*css.RuleUsage, timestamp float64, err error) func github.com/chromedp/cdproto/css.(*TrackComputedStyleUpdatesParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/database.(*DisableParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/database.(*EnableParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/database.(*ExecuteSQLParams).Do(ctx Context) (columnNames []string, values []easyjson.RawMessage, sqlError *database.Error, err error) func github.com/chromedp/cdproto/database.(*GetDatabaseTableNamesParams).Do(ctx Context) (tableNames []string, err error) func github.com/chromedp/cdproto/debugger.(*ContinueToLocationParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/debugger.(*DisableParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/debugger.(*DisassembleWasmModuleParams).Do(ctx Context) (streamID string, totalNumberOfLines int64, functionBodyOffsets []int64, chunk *debugger.WasmDisassemblyChunk, err error) func github.com/chromedp/cdproto/debugger.(*EnableParams).Do(ctx Context) (debuggerID runtime.UniqueDebuggerID, err error) func github.com/chromedp/cdproto/debugger.(*EvaluateOnCallFrameParams).Do(ctx Context) (result *runtime.RemoteObject, exceptionDetails *runtime.ExceptionDetails, err error) func github.com/chromedp/cdproto/debugger.(*GetPossibleBreakpointsParams).Do(ctx Context) (locations []*debugger.BreakLocation, err error) func github.com/chromedp/cdproto/debugger.(*GetScriptSourceParams).Do(ctx Context) (scriptSource string, bytecode []byte, err error) func github.com/chromedp/cdproto/debugger.(*GetStackTraceParams).Do(ctx Context) (stackTrace *runtime.StackTrace, err error) func github.com/chromedp/cdproto/debugger.(*NextWasmDisassemblyChunkParams).Do(ctx Context) (chunk *debugger.WasmDisassemblyChunk, err error) func github.com/chromedp/cdproto/debugger.(*PauseParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/debugger.(*RemoveBreakpointParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/debugger.(*RestartFrameParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/debugger.(*ResumeParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/debugger.(*SearchInContentParams).Do(ctx Context) (result []*debugger.SearchMatch, err error) func github.com/chromedp/cdproto/debugger.(*SetAsyncCallStackDepthParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/debugger.(*SetBlackboxedRangesParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/debugger.(*SetBlackboxPatternsParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/debugger.(*SetBreakpointByURLParams).Do(ctx Context) (breakpointID debugger.BreakpointID, locations []*debugger.Location, err error) func github.com/chromedp/cdproto/debugger.(*SetBreakpointOnFunctionCallParams).Do(ctx Context) (breakpointID debugger.BreakpointID, err error) func github.com/chromedp/cdproto/debugger.(*SetBreakpointParams).Do(ctx Context) (breakpointID debugger.BreakpointID, actualLocation *debugger.Location, err error) func github.com/chromedp/cdproto/debugger.(*SetBreakpointsActiveParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/debugger.(*SetInstrumentationBreakpointParams).Do(ctx Context) (breakpointID debugger.BreakpointID, err error) func github.com/chromedp/cdproto/debugger.(*SetPauseOnExceptionsParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/debugger.(*SetReturnValueParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/debugger.(*SetScriptSourceParams).Do(ctx Context) (status debugger.SetScriptSourceStatus, exceptionDetails *runtime.ExceptionDetails, err error) func github.com/chromedp/cdproto/debugger.(*SetSkipAllPausesParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/debugger.(*SetVariableValueParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/debugger.(*StepIntoParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/debugger.(*StepOutParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/debugger.(*StepOverParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/deviceaccess.(*CancelPromptParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/deviceaccess.(*DisableParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/deviceaccess.(*EnableParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/deviceaccess.(*SelectPromptParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/deviceorientation.(*ClearDeviceOrientationOverrideParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/deviceorientation.(*SetDeviceOrientationOverrideParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/dom.(*CollectClassNamesFromSubtreeParams).Do(ctx Context) (classNames []string, err error) func github.com/chromedp/cdproto/dom.(*CopyToParams).Do(ctx Context) (nodeID cdp.NodeID, err error) func github.com/chromedp/cdproto/dom.(*DescribeNodeParams).Do(ctx Context) (node *cdp.Node, err error) func github.com/chromedp/cdproto/dom.(*DisableParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/dom.(*DiscardSearchResultsParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/dom.(*EnableParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/dom.(*FocusParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/dom.(*GetAttributesParams).Do(ctx Context) (attributes []string, err error) func github.com/chromedp/cdproto/dom.(*GetBoxModelParams).Do(ctx Context) (model *dom.BoxModel, err error) func github.com/chromedp/cdproto/dom.(*GetContainerForNodeParams).Do(ctx Context) (nodeID cdp.NodeID, err error) func github.com/chromedp/cdproto/dom.(*GetContentQuadsParams).Do(ctx Context) (quads []dom.Quad, err error) func github.com/chromedp/cdproto/dom.(*GetDocumentParams).Do(ctx Context) (root *cdp.Node, err error) func github.com/chromedp/cdproto/dom.(*GetFileInfoParams).Do(ctx Context) (path string, err error) func github.com/chromedp/cdproto/dom.(*GetFrameOwnerParams).Do(ctx Context) (backendNodeID cdp.BackendNodeID, nodeID cdp.NodeID, err error) func github.com/chromedp/cdproto/dom.(*GetNodeForLocationParams).Do(ctx Context) (backendNodeID cdp.BackendNodeID, frameID cdp.FrameID, nodeID cdp.NodeID, err error) func github.com/chromedp/cdproto/dom.(*GetNodesForSubtreeByStyleParams).Do(ctx Context) (nodeIDs []cdp.NodeID, err error) func github.com/chromedp/cdproto/dom.(*GetNodeStackTracesParams).Do(ctx Context) (creation *runtime.StackTrace, err error) func github.com/chromedp/cdproto/dom.(*GetOuterHTMLParams).Do(ctx Context) (outerHTML string, err error) func github.com/chromedp/cdproto/dom.(*GetQueryingDescendantsForContainerParams).Do(ctx Context) (nodeIDs []cdp.NodeID, err error) func github.com/chromedp/cdproto/dom.(*GetRelayoutBoundaryParams).Do(ctx Context) (nodeID cdp.NodeID, err error) func github.com/chromedp/cdproto/dom.(*GetSearchResultsParams).Do(ctx Context) (nodeIDs []cdp.NodeID, err error) func github.com/chromedp/cdproto/dom.(*GetTopLayerElementsParams).Do(ctx Context) (nodeIDs []cdp.NodeID, err error) func github.com/chromedp/cdproto/dom.(*MarkUndoableStateParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/dom.(*MoveToParams).Do(ctx Context) (nodeID cdp.NodeID, err error) func github.com/chromedp/cdproto/dom.(*PerformSearchParams).Do(ctx Context) (searchID string, resultCount int64, err error) func github.com/chromedp/cdproto/dom.(*PushNodeByPathToFrontendParams).Do(ctx Context) (nodeID cdp.NodeID, err error) func github.com/chromedp/cdproto/dom.(*PushNodesByBackendIDsToFrontendParams).Do(ctx Context) (nodeIDs []cdp.NodeID, err error) func github.com/chromedp/cdproto/dom.(*QuerySelectorAllParams).Do(ctx Context) (nodeIDs []cdp.NodeID, err error) func github.com/chromedp/cdproto/dom.(*QuerySelectorParams).Do(ctx Context) (nodeID cdp.NodeID, err error) func github.com/chromedp/cdproto/dom.(*RedoParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/dom.(*RemoveAttributeParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/dom.(*RemoveNodeParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/dom.(*RequestChildNodesParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/dom.(*RequestNodeParams).Do(ctx Context) (nodeID cdp.NodeID, err error) func github.com/chromedp/cdproto/dom.(*ResolveNodeParams).Do(ctx Context) (object *runtime.RemoteObject, err error) func github.com/chromedp/cdproto/dom.(*ScrollIntoViewIfNeededParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/dom.(*SetAttributesAsTextParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/dom.(*SetAttributeValueParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/dom.(*SetFileInputFilesParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/dom.(*SetInspectedNodeParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/dom.(*SetNodeNameParams).Do(ctx Context) (nodeID cdp.NodeID, err error) func github.com/chromedp/cdproto/dom.(*SetNodeStackTracesEnabledParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/dom.(*SetNodeValueParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/dom.(*SetOuterHTMLParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/dom.(*UndoParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/domdebugger.(*GetEventListenersParams).Do(ctx Context) (listeners []*domdebugger.EventListener, err error) func github.com/chromedp/cdproto/domdebugger.(*RemoveDOMBreakpointParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/domdebugger.(*RemoveEventListenerBreakpointParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/domdebugger.(*RemoveXHRBreakpointParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/domdebugger.(*SetBreakOnCSPViolationParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/domdebugger.(*SetDOMBreakpointParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/domdebugger.(*SetEventListenerBreakpointParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/domdebugger.(*SetXHRBreakpointParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/domsnapshot.(*CaptureSnapshotParams).Do(ctx Context) (documents []*domsnapshot.DocumentSnapshot, strings []string, err error) func github.com/chromedp/cdproto/domsnapshot.(*DisableParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/domsnapshot.(*EnableParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/domstorage.(*ClearParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/domstorage.(*DisableParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/domstorage.(*EnableParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/domstorage.(*GetDOMStorageItemsParams).Do(ctx Context) (entries []domstorage.Item, err error) func github.com/chromedp/cdproto/domstorage.(*RemoveDOMStorageItemParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/domstorage.(*SetDOMStorageItemParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/emulation.(*CanEmulateParams).Do(ctx Context) (result bool, err error) func github.com/chromedp/cdproto/emulation.(*ClearDeviceMetricsOverrideParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/emulation.(*ClearGeolocationOverrideParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/emulation.(*ClearIdleOverrideParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/emulation.(*ResetPageScaleFactorParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/emulation.(*SetAutoDarkModeOverrideParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/emulation.(*SetAutomationOverrideParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/emulation.(*SetCPUThrottlingRateParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/emulation.(*SetDefaultBackgroundColorOverrideParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/emulation.(*SetDeviceMetricsOverrideParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/emulation.(*SetDisabledImageTypesParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/emulation.(*SetDocumentCookieDisabledParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/emulation.(*SetEmitTouchEventsForMouseParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/emulation.(*SetEmulatedMediaParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/emulation.(*SetEmulatedVisionDeficiencyParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/emulation.(*SetFocusEmulationEnabledParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/emulation.(*SetGeolocationOverrideParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/emulation.(*SetHardwareConcurrencyOverrideParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/emulation.(*SetIdleOverrideParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/emulation.(*SetLocaleOverrideParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/emulation.(*SetPageScaleFactorParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/emulation.(*SetScriptExecutionDisabledParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/emulation.(*SetScrollbarsHiddenParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/emulation.(*SetTimezoneOverrideParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/emulation.(*SetTouchEmulationEnabledParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/emulation.(*SetUserAgentOverrideParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/emulation.(*SetVirtualTimePolicyParams).Do(ctx Context) (virtualTimeTicksBase float64, err error) func github.com/chromedp/cdproto/eventbreakpoints.(*DisableParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/eventbreakpoints.(*RemoveInstrumentationBreakpointParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/eventbreakpoints.(*SetInstrumentationBreakpointParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/fedcm.(*ConfirmIdpLoginParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/fedcm.(*DisableParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/fedcm.(*DismissDialogParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/fedcm.(*EnableParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/fedcm.(*ResetCooldownParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/fedcm.(*SelectAccountParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/fetch.(*ContinueRequestParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/fetch.(*ContinueResponseParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/fetch.(*ContinueWithAuthParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/fetch.(*DisableParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/fetch.(*EnableParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/fetch.(*FailRequestParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/fetch.(*FulfillRequestParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/fetch.(*GetResponseBodyParams).Do(ctx Context) (body []byte, err error) func github.com/chromedp/cdproto/fetch.(*TakeResponseBodyAsStreamParams).Do(ctx Context) (stream io.StreamHandle, err error) func github.com/chromedp/cdproto/headlessexperimental.(*BeginFrameParams).Do(ctx Context) (hasDamage bool, screenshotData []byte, err error) func github.com/chromedp/cdproto/heapprofiler.(*AddInspectedHeapObjectParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/heapprofiler.(*CollectGarbageParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/heapprofiler.(*DisableParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/heapprofiler.(*EnableParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/heapprofiler.(*GetHeapObjectIDParams).Do(ctx Context) (heapSnapshotObjectID heapprofiler.HeapSnapshotObjectID, err error) func github.com/chromedp/cdproto/heapprofiler.(*GetObjectByHeapObjectIDParams).Do(ctx Context) (result *runtime.RemoteObject, err error) func github.com/chromedp/cdproto/heapprofiler.(*GetSamplingProfileParams).Do(ctx Context) (profile *heapprofiler.SamplingHeapProfile, err error) func github.com/chromedp/cdproto/heapprofiler.(*StartSamplingParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/heapprofiler.(*StartTrackingHeapObjectsParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/heapprofiler.(*StopSamplingParams).Do(ctx Context) (profile *heapprofiler.SamplingHeapProfile, err error) func github.com/chromedp/cdproto/heapprofiler.(*StopTrackingHeapObjectsParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/heapprofiler.(*TakeHeapSnapshotParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/indexeddb.(*ClearObjectStoreParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/indexeddb.(*DeleteDatabaseParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/indexeddb.(*DeleteObjectStoreEntriesParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/indexeddb.(*DisableParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/indexeddb.(*EnableParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/indexeddb.(*GetMetadataParams).Do(ctx Context) (entriesCount float64, keyGeneratorValue float64, err error) func github.com/chromedp/cdproto/indexeddb.(*RequestDatabaseNamesParams).Do(ctx Context) (databaseNames []string, err error) func github.com/chromedp/cdproto/indexeddb.(*RequestDatabaseParams).Do(ctx Context) (databaseWithObjectStores *indexeddb.DatabaseWithObjectStores, err error) func github.com/chromedp/cdproto/indexeddb.(*RequestDataParams).Do(ctx Context) (objectStoreDataEntries []*indexeddb.DataEntry, hasMore bool, err error) func github.com/chromedp/cdproto/input.(*CancelDraggingParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/input.(*DispatchDragEventParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/input.(*DispatchKeyEventParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/input.(*DispatchMouseEventParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/input.(*DispatchTouchEventParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/input.(*EmulateTouchFromMouseEventParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/input.(*ImeSetCompositionParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/input.(*InsertTextParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/input.(*SetIgnoreInputEventsParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/input.(*SetInterceptDragsParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/input.(*SynthesizePinchGestureParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/input.(*SynthesizeScrollGestureParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/input.(*SynthesizeTapGestureParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/inspector.(*DisableParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/inspector.(*EnableParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/io.(*CloseParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/io.(*ReadParams).Do(ctx Context) (data string, eof bool, err error) func github.com/chromedp/cdproto/io.(*ResolveBlobParams).Do(ctx Context) (uuid string, err error) func github.com/chromedp/cdproto/layertree.(*CompositingReasonsParams).Do(ctx Context) (compositingReasons []string, compositingReasonIDs []string, err error) func github.com/chromedp/cdproto/layertree.(*DisableParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/layertree.(*EnableParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/layertree.(*LoadSnapshotParams).Do(ctx Context) (snapshotID layertree.SnapshotID, err error) func github.com/chromedp/cdproto/layertree.(*MakeSnapshotParams).Do(ctx Context) (snapshotID layertree.SnapshotID, err error) func github.com/chromedp/cdproto/layertree.(*ProfileSnapshotParams).Do(ctx Context) (timings []layertree.PaintProfile, err error) func github.com/chromedp/cdproto/layertree.(*ReleaseSnapshotParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/layertree.(*ReplaySnapshotParams).Do(ctx Context) (dataURL string, err error) func github.com/chromedp/cdproto/layertree.(*SnapshotCommandLogParams).Do(ctx Context) (commandLog []easyjson.RawMessage, err error) func github.com/chromedp/cdproto/log.(*ClearParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/log.(*DisableParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/log.(*EnableParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/log.(*StartViolationsReportParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/log.(*StopViolationsReportParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/media.(*DisableParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/media.(*EnableParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/memory.(*ForciblyPurgeJavaScriptMemoryParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/memory.(*GetAllTimeSamplingProfileParams).Do(ctx Context) (profile *memory.SamplingProfile, err error) func github.com/chromedp/cdproto/memory.(*GetBrowserSamplingProfileParams).Do(ctx Context) (profile *memory.SamplingProfile, err error) func github.com/chromedp/cdproto/memory.(*GetDOMCountersParams).Do(ctx Context) (documents int64, nodes int64, jsEventListeners int64, err error) func github.com/chromedp/cdproto/memory.(*GetSamplingProfileParams).Do(ctx Context) (profile *memory.SamplingProfile, err error) func github.com/chromedp/cdproto/memory.(*PrepareForLeakDetectionParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/memory.(*SetPressureNotificationsSuppressedParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/memory.(*SimulatePressureNotificationParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/memory.(*StartSamplingParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/memory.(*StopSamplingParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/network.(*ClearAcceptedEncodingsOverrideParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/network.(*ClearBrowserCacheParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/network.(*ClearBrowserCookiesParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/network.(*DeleteCookiesParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/network.(*DisableParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/network.(*EmulateNetworkConditionsParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/network.(*EnableParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/network.(*EnableReportingAPIParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/network.(*GetCertificateParams).Do(ctx Context) (tableNames []string, err error) func github.com/chromedp/cdproto/network.(*GetCookiesParams).Do(ctx Context) (cookies []*network.Cookie, err error) func github.com/chromedp/cdproto/network.(*GetRequestPostDataParams).Do(ctx Context) (postData string, err error) func github.com/chromedp/cdproto/network.(*GetResponseBodyForInterceptionParams).Do(ctx Context) (body []byte, err error) func github.com/chromedp/cdproto/network.(*GetResponseBodyParams).Do(ctx Context) (body []byte, err error) func github.com/chromedp/cdproto/network.(*GetSecurityIsolationStatusParams).Do(ctx Context) (status *network.SecurityIsolationStatus, err error) func github.com/chromedp/cdproto/network.(*LoadNetworkResourceParams).Do(ctx Context) (resource *network.LoadNetworkResourcePageResult, err error) func github.com/chromedp/cdproto/network.(*ReplayXHRParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/network.(*SearchInResponseBodyParams).Do(ctx Context) (result []*debugger.SearchMatch, err error) func github.com/chromedp/cdproto/network.(*SetAcceptedEncodingsParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/network.(*SetAttachDebugStackParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/network.(*SetBlockedURLSParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/network.(*SetBypassServiceWorkerParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/network.(*SetCacheDisabledParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/network.(*SetCookieParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/network.(*SetCookiesParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/network.(*SetExtraHTTPHeadersParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/network.(*TakeResponseBodyForInterceptionAsStreamParams).Do(ctx Context) (stream io.StreamHandle, err error) func github.com/chromedp/cdproto/overlay.(*DisableParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/overlay.(*EnableParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/overlay.(*GetGridHighlightObjectsForTestParams).Do(ctx Context) (highlights easyjson.RawMessage, err error) func github.com/chromedp/cdproto/overlay.(*GetHighlightObjectForTestParams).Do(ctx Context) (highlight easyjson.RawMessage, err error) func github.com/chromedp/cdproto/overlay.(*GetSourceOrderHighlightObjectForTestParams).Do(ctx Context) (highlight easyjson.RawMessage, err error) func github.com/chromedp/cdproto/overlay.(*HideHighlightParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/overlay.(*HighlightNodeParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/overlay.(*HighlightQuadParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/overlay.(*HighlightRectParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/overlay.(*HighlightSourceOrderParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/overlay.(*SetInspectModeParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/overlay.(*SetPausedInDebuggerMessageParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/overlay.(*SetShowAdHighlightsParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/overlay.(*SetShowContainerQueryOverlaysParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/overlay.(*SetShowDebugBordersParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/overlay.(*SetShowFlexOverlaysParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/overlay.(*SetShowFPSCounterParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/overlay.(*SetShowGridOverlaysParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/overlay.(*SetShowHingeParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/overlay.(*SetShowIsolatedElementsParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/overlay.(*SetShowLayoutShiftRegionsParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/overlay.(*SetShowPaintRectsParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/overlay.(*SetShowScrollBottleneckRectsParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/overlay.(*SetShowScrollSnapOverlaysParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/overlay.(*SetShowViewportSizeOnResizeParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/overlay.(*SetShowWebVitalsParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/page.(*AddCompilationCacheParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/page.(*AddScriptToEvaluateOnNewDocumentParams).Do(ctx Context) (identifier page.ScriptIdentifier, err error) func github.com/chromedp/cdproto/page.(*BringToFrontParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/page.(*CaptureScreenshotParams).Do(ctx Context) (data []byte, err error) func github.com/chromedp/cdproto/page.(*CaptureSnapshotParams).Do(ctx Context) (data string, err error) func github.com/chromedp/cdproto/page.(*ClearCompilationCacheParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/page.(*CloseParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/page.(*CrashParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/page.(*CreateIsolatedWorldParams).Do(ctx Context) (executionContextID runtime.ExecutionContextID, err error) func github.com/chromedp/cdproto/page.(*DisableParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/page.(*EnableParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/page.(*GenerateTestReportParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/page.(*GetAdScriptIDParams).Do(ctx Context) (adScriptID *page.AdScriptID, err error) func github.com/chromedp/cdproto/page.(*GetAppIDParams).Do(ctx Context) (appID string, recommendedID string, err error) func github.com/chromedp/cdproto/page.(*GetAppManifestParams).Do(ctx Context) (url string, errors []*page.AppManifestError, data string, parsed *page.AppManifestParsedProperties, err error) func github.com/chromedp/cdproto/page.(*GetFrameTreeParams).Do(ctx Context) (frameTree *page.FrameTree, err error) func github.com/chromedp/cdproto/page.(*GetInstallabilityErrorsParams).Do(ctx Context) (installabilityErrors []*page.InstallabilityError, err error) func github.com/chromedp/cdproto/page.(*GetLayoutMetricsParams).Do(ctx Context) (layoutViewport *page.LayoutViewport, visualViewport *page.VisualViewport, contentSize *dom.Rect, cssLayoutViewport *page.LayoutViewport, cssVisualViewport *page.VisualViewport, cssContentSize *dom.Rect, err error) func github.com/chromedp/cdproto/page.(*GetNavigationHistoryParams).Do(ctx Context) (currentIndex int64, entries []*page.NavigationEntry, err error) func github.com/chromedp/cdproto/page.(*GetOriginTrialsParams).Do(ctx Context) (originTrials []*cdp.OriginTrial, err error) func github.com/chromedp/cdproto/page.(*GetPermissionsPolicyStateParams).Do(ctx Context) (states []*page.PermissionsPolicyFeatureState, err error) func github.com/chromedp/cdproto/page.(*GetResourceContentParams).Do(ctx Context) (content []byte, err error) func github.com/chromedp/cdproto/page.(*GetResourceTreeParams).Do(ctx Context) (frameTree *page.FrameResourceTree, err error) func github.com/chromedp/cdproto/page.(*HandleJavaScriptDialogParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/page.(*NavigateParams).Do(ctx Context) (frameID cdp.FrameID, loaderID cdp.LoaderID, errorText string, err error) func github.com/chromedp/cdproto/page.(*NavigateToHistoryEntryParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/page.(*PrintToPDFParams).Do(ctx Context) (data []byte, stream io.StreamHandle, err error) func github.com/chromedp/cdproto/page.(*ProduceCompilationCacheParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/page.(*ReloadParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/page.(*RemoveScriptToEvaluateOnNewDocumentParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/page.(*ResetNavigationHistoryParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/page.(*ScreencastFrameAckParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/page.(*SearchInResourceParams).Do(ctx Context) (result []*debugger.SearchMatch, err error) func github.com/chromedp/cdproto/page.(*SetAdBlockingEnabledParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/page.(*SetBypassCSPParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/page.(*SetDocumentContentParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/page.(*SetFontFamiliesParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/page.(*SetFontSizesParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/page.(*SetInterceptFileChooserDialogParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/page.(*SetLifecycleEventsEnabledParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/page.(*SetPrerenderingAllowedParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/page.(*SetRPHRegistrationModeParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/page.(*SetSPCTransactionModeParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/page.(*SetWebLifecycleStateParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/page.(*StartScreencastParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/page.(*StopLoadingParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/page.(*StopScreencastParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/page.(*WaitForDebuggerParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/performance.(*DisableParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/performance.(*EnableParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/performance.(*GetMetricsParams).Do(ctx Context) (metrics []*performance.Metric, err error) func github.com/chromedp/cdproto/performancetimeline.(*EnableParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/preload.(*DisableParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/preload.(*EnableParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/profiler.(*DisableParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/profiler.(*EnableParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/profiler.(*GetBestEffortCoverageParams).Do(ctx Context) (result []*profiler.ScriptCoverage, err error) func github.com/chromedp/cdproto/profiler.(*SetSamplingIntervalParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/profiler.(*StartParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/profiler.(*StartPreciseCoverageParams).Do(ctx Context) (timestamp float64, err error) func github.com/chromedp/cdproto/profiler.(*StopParams).Do(ctx Context) (profile *profiler.Profile, err error) func github.com/chromedp/cdproto/profiler.(*StopPreciseCoverageParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/profiler.(*TakePreciseCoverageParams).Do(ctx Context) (result []*profiler.ScriptCoverage, timestamp float64, err error) func github.com/chromedp/cdproto/runtime.(*AddBindingParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/runtime.(*AwaitPromiseParams).Do(ctx Context) (result *runtime.RemoteObject, exceptionDetails *runtime.ExceptionDetails, err error) func github.com/chromedp/cdproto/runtime.(*CallFunctionOnParams).Do(ctx Context) (result *runtime.RemoteObject, exceptionDetails *runtime.ExceptionDetails, err error) func github.com/chromedp/cdproto/runtime.(*CompileScriptParams).Do(ctx Context) (scriptID runtime.ScriptID, exceptionDetails *runtime.ExceptionDetails, err error) func github.com/chromedp/cdproto/runtime.(*DisableParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/runtime.(*DiscardConsoleEntriesParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/runtime.(*EnableParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/runtime.(*EvaluateParams).Do(ctx Context) (result *runtime.RemoteObject, exceptionDetails *runtime.ExceptionDetails, err error) func github.com/chromedp/cdproto/runtime.(*GetExceptionDetailsParams).Do(ctx Context) (exceptionDetails *runtime.ExceptionDetails, err error) func github.com/chromedp/cdproto/runtime.(*GetHeapUsageParams).Do(ctx Context) (usedSize float64, totalSize float64, err error) func github.com/chromedp/cdproto/runtime.(*GetIsolateIDParams).Do(ctx Context) (id string, err error) func github.com/chromedp/cdproto/runtime.(*GetPropertiesParams).Do(ctx Context) (result []*runtime.PropertyDescriptor, internalProperties []*runtime.InternalPropertyDescriptor, privateProperties []*runtime.PrivatePropertyDescriptor, exceptionDetails *runtime.ExceptionDetails, err error) func github.com/chromedp/cdproto/runtime.(*GlobalLexicalScopeNamesParams).Do(ctx Context) (names []string, err error) func github.com/chromedp/cdproto/runtime.(*QueryObjectsParams).Do(ctx Context) (objects *runtime.RemoteObject, err error) func github.com/chromedp/cdproto/runtime.(*ReleaseObjectGroupParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/runtime.(*ReleaseObjectParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/runtime.(*RemoveBindingParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/runtime.(*RunIfWaitingForDebuggerParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/runtime.(*RunScriptParams).Do(ctx Context) (result *runtime.RemoteObject, exceptionDetails *runtime.ExceptionDetails, err error) func github.com/chromedp/cdproto/runtime.(*SetCustomObjectFormatterEnabledParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/runtime.(*SetMaxCallStackSizeToCaptureParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/runtime.(*TerminateExecutionParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/security.(*DisableParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/security.(*EnableParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/security.(*SetIgnoreCertificateErrorsParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/serviceworker.(*DeliverPushMessageParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/serviceworker.(*DisableParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/serviceworker.(*DispatchPeriodicSyncEventParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/serviceworker.(*DispatchSyncEventParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/serviceworker.(*EnableParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/serviceworker.(*InspectWorkerParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/serviceworker.(*SetForceUpdateOnPageLoadParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/serviceworker.(*SkipWaitingParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/serviceworker.(*StartWorkerParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/serviceworker.(*StopAllWorkersParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/serviceworker.(*StopWorkerParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/serviceworker.(*UnregisterParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/serviceworker.(*UpdateRegistrationParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/storage.(*ClearCookiesParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/storage.(*ClearDataForOriginParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/storage.(*ClearDataForStorageKeyParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/storage.(*ClearSharedStorageEntriesParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/storage.(*ClearTrustTokensParams).Do(ctx Context) (didDeleteTokens bool, err error) func github.com/chromedp/cdproto/storage.(*DeleteSharedStorageEntryParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/storage.(*DeleteStorageBucketParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/storage.(*GetCookiesParams).Do(ctx Context) (cookies []*network.Cookie, err error) func github.com/chromedp/cdproto/storage.(*GetInterestGroupDetailsParams).Do(ctx Context) (details *storage.InterestGroupDetails, err error) func github.com/chromedp/cdproto/storage.(*GetSharedStorageEntriesParams).Do(ctx Context) (entries []*storage.SharedStorageEntry, err error) func github.com/chromedp/cdproto/storage.(*GetSharedStorageMetadataParams).Do(ctx Context) (metadata *storage.SharedStorageMetadata, err error) func github.com/chromedp/cdproto/storage.(*GetStorageKeyForFrameParams).Do(ctx Context) (storageKey storage.SerializedStorageKey, err error) func github.com/chromedp/cdproto/storage.(*GetTrustTokensParams).Do(ctx Context) (tokens []*storage.TrustTokens, err error) func github.com/chromedp/cdproto/storage.(*GetUsageAndQuotaParams).Do(ctx Context) (usage float64, quota float64, overrideActive bool, usageBreakdown []*storage.UsageForType, err error) func github.com/chromedp/cdproto/storage.(*OverrideQuotaForOriginParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/storage.(*ResetSharedStorageBudgetParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/storage.(*RunBounceTrackingMitigationsParams).Do(ctx Context) (deletedSites []string, err error) func github.com/chromedp/cdproto/storage.(*SetAttributionReportingLocalTestingModeParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/storage.(*SetAttributionReportingTrackingParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/storage.(*SetCookiesParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/storage.(*SetInterestGroupTrackingParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/storage.(*SetSharedStorageEntryParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/storage.(*SetSharedStorageTrackingParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/storage.(*SetStorageBucketTrackingParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/storage.(*TrackCacheStorageForOriginParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/storage.(*TrackCacheStorageForStorageKeyParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/storage.(*TrackIndexedDBForOriginParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/storage.(*TrackIndexedDBForStorageKeyParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/storage.(*UntrackCacheStorageForOriginParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/storage.(*UntrackCacheStorageForStorageKeyParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/storage.(*UntrackIndexedDBForOriginParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/storage.(*UntrackIndexedDBForStorageKeyParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/systeminfo.(*GetFeatureStateParams).Do(ctx Context) (featureEnabled bool, err error) func github.com/chromedp/cdproto/systeminfo.(*GetInfoParams).Do(ctx Context) (gpu *systeminfo.GPUInfo, modelName string, modelVersion string, commandLine string, err error) func github.com/chromedp/cdproto/systeminfo.(*GetProcessInfoParams).Do(ctx Context) (processInfo []*systeminfo.ProcessInfo, err error) func github.com/chromedp/cdproto/target.(*ActivateTargetParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/target.(*AttachToBrowserTargetParams).Do(ctx Context) (sessionID target.SessionID, err error) func github.com/chromedp/cdproto/target.(*AttachToTargetParams).Do(ctx Context) (sessionID target.SessionID, err error) func github.com/chromedp/cdproto/target.(*AutoAttachRelatedParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/target.(*CloseTargetParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/target.(*CreateBrowserContextParams).Do(ctx Context) (browserContextID cdp.BrowserContextID, err error) func github.com/chromedp/cdproto/target.(*CreateTargetParams).Do(ctx Context) (targetID target.ID, err error) func github.com/chromedp/cdproto/target.(*DetachFromTargetParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/target.(*DisposeBrowserContextParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/target.(*ExposeDevToolsProtocolParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/target.(*GetBrowserContextsParams).Do(ctx Context) (browserContextIDs []cdp.BrowserContextID, err error) func github.com/chromedp/cdproto/target.(*GetTargetInfoParams).Do(ctx Context) (targetInfo *target.Info, err error) func github.com/chromedp/cdproto/target.(*GetTargetsParams).Do(ctx Context) (targetInfos []*target.Info, err error) func github.com/chromedp/cdproto/target.(*SetAutoAttachParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/target.(*SetDiscoverTargetsParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/target.(*SetRemoteLocationsParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/tethering.(*BindParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/tethering.(*UnbindParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/tracing.(*EndParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/tracing.(*GetCategoriesParams).Do(ctx Context) (categories []string, err error) func github.com/chromedp/cdproto/tracing.(*RecordClockSyncMarkerParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/tracing.(*RequestMemoryDumpParams).Do(ctx Context) (dumpGUID string, success bool, err error) func github.com/chromedp/cdproto/tracing.(*StartParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/webaudio.(*DisableParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/webaudio.(*EnableParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/webaudio.(*GetRealtimeDataParams).Do(ctx Context) (realtimeData *webaudio.ContextRealtimeData, err error) func github.com/chromedp/cdproto/webauthn.(*AddCredentialParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/webauthn.(*AddVirtualAuthenticatorParams).Do(ctx Context) (authenticatorID webauthn.AuthenticatorID, err error) func github.com/chromedp/cdproto/webauthn.(*ClearCredentialsParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/webauthn.(*DisableParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/webauthn.(*EnableParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/webauthn.(*GetCredentialParams).Do(ctx Context) (credential *webauthn.Credential, err error) func github.com/chromedp/cdproto/webauthn.(*GetCredentialsParams).Do(ctx Context) (credentials []*webauthn.Credential, err error) func github.com/chromedp/cdproto/webauthn.(*RemoveCredentialParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/webauthn.(*RemoveVirtualAuthenticatorParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/webauthn.(*SetAutomaticPresenceSimulationParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/webauthn.(*SetResponseOverrideBitsParams).Do(ctx Context) (err error) func github.com/chromedp/cdproto/webauthn.(*SetUserVerifiedParams).Do(ctx Context) (err error) func github.com/chromedp/chromedp.Cancel(ctx Context) error func github.com/chromedp/chromedp.DialContext(ctx Context, urlstr string, opts ...chromedp.DialOption) (*chromedp.Conn, error) func github.com/chromedp/chromedp.FromContext(ctx Context) *chromedp.Context func github.com/chromedp/chromedp.ListenBrowser(ctx Context, fn func(ev interface{})) func github.com/chromedp/chromedp.ListenTarget(ctx Context, fn func(ev interface{})) func github.com/chromedp/chromedp.NewBrowser(ctx Context, urlstr string, opts ...chromedp.BrowserOption) (*chromedp.Browser, error) func github.com/chromedp/chromedp.NewContext(parent Context, opts ...chromedp.ContextOption) (Context, CancelFunc) func github.com/chromedp/chromedp.NewExecAllocator(parent Context, opts ...chromedp.ExecAllocatorOption) (Context, CancelFunc) func github.com/chromedp/chromedp.NewRemoteAllocator(parent Context, url string, opts ...chromedp.RemoteAllocatorOption) (Context, CancelFunc) func github.com/chromedp/chromedp.Run(ctx Context, actions ...chromedp.Action) error func github.com/chromedp/chromedp.RunResponse(ctx Context, actions ...chromedp.Action) (*network.Response, error) func github.com/chromedp/chromedp.Targets(ctx Context) ([]*target.Info, error) func github.com/chromedp/chromedp.WaitNewTarget(ctx Context, fn func(*target.Info) bool) <-chan target.ID func github.com/chromedp/chromedp.Action.Do(Context) error func github.com/chromedp/chromedp.ActionFunc.Do(ctx Context) error func github.com/chromedp/chromedp.Allocator.Allocate(Context, ...chromedp.BrowserOption) (*chromedp.Browser, error) func github.com/chromedp/chromedp.(*Browser).Execute(ctx Context, method string, params easyjson.Marshaler, res easyjson.Unmarshaler) error func github.com/chromedp/chromedp.CallAction.Do(Context) error func github.com/chromedp/chromedp.(*Conn).Read(_ Context, msg *cdproto.Message) error func github.com/chromedp/chromedp.(*Conn).Write(_ Context, msg *cdproto.Message) error func github.com/chromedp/chromedp.EmulateAction.Do(Context) error func github.com/chromedp/chromedp.EvaluateAction.Do(Context) error func github.com/chromedp/chromedp.(*ExecAllocator).Allocate(ctx Context, opts ...chromedp.BrowserOption) (*chromedp.Browser, error) func github.com/chromedp/chromedp.KeyAction.Do(Context) error func github.com/chromedp/chromedp.MouseAction.Do(Context) error func github.com/chromedp/chromedp.NavigateAction.Do(Context) error func github.com/chromedp/chromedp.PollAction.Do(Context) error func github.com/chromedp/chromedp.QueryAction.Do(Context) error func github.com/chromedp/chromedp.(*RemoteAllocator).Allocate(ctx Context, opts ...chromedp.BrowserOption) (*chromedp.Browser, error) func github.com/chromedp/chromedp.(*Selector).Do(ctx Context) error func github.com/chromedp/chromedp.(*Target).Execute(ctx Context, method string, params easyjson.Marshaler, res easyjson.Unmarshaler) error func github.com/chromedp/chromedp.Tasks.Do(ctx Context) error func github.com/chromedp/chromedp.Transport.Read(Context, *cdproto.Message) error func github.com/chromedp/chromedp.Transport.Write(Context, *cdproto.Message) error func github.com/coder/websocket.Dial(ctx Context, u string, opts *websocket.DialOptions) (*websocket.Conn, *http.Response, error) func github.com/coder/websocket.NetConn(ctx Context, c *websocket.Conn, msgType websocket.MessageType) net.Conn func github.com/coder/websocket.(*Conn).CloseRead(ctx Context) Context func github.com/coder/websocket.(*Conn).Ping(ctx Context) error func github.com/coder/websocket.(*Conn).Read(ctx Context) (websocket.MessageType, []byte, error) func github.com/coder/websocket.(*Conn).Reader(ctx Context) (websocket.MessageType, io.Reader, error) func github.com/coder/websocket.(*Conn).Write(ctx Context, typ websocket.MessageType, p []byte) error func github.com/coder/websocket.(*Conn).Writer(ctx Context, typ websocket.MessageType) (io.WriteCloser, error) func github.com/failsafe-go/failsafe-go.Executor.WithContext(ctx Context) failsafe.Executor[R] func github.com/failsafe-go/failsafe-go/internal/util.MergeContexts(ctx1, ctx2 Context) (Context, CancelCauseFunc) func github.com/gliderlabs/ssh.(*Server).Shutdown(ctx Context) error func github.com/go-logr/logr.FromContext(ctx Context) (logr.Logger, error) func github.com/go-logr/logr.FromContextAsSlogLogger(ctx Context) *slog.Logger func github.com/go-logr/logr.FromContextOrDiscard(ctx Context) logr.Logger func github.com/go-logr/logr.NewContext(ctx Context, logger logr.Logger) Context func github.com/go-logr/logr.NewContextWithSlogLogger(ctx Context, logger *slog.Logger) Context func github.com/go-logr/logr.SlogSink.Handle(ctx Context, record slog.Record) error func github.com/gobwas/ws.Dial(ctx Context, urlstr string) (net.Conn, *bufio.Reader, ws.Handshake, error) func github.com/gobwas/ws.Dialer.Dial(ctx Context, urlstr string) (conn net.Conn, br *bufio.Reader, hs ws.Handshake, err error) func github.com/gobwas/ws/wsutil.(*DebugDialer).Dial(ctx Context, urlstr string) (conn net.Conn, br *bufio.Reader, hs ws.Handshake, err error) func github.com/goccy/go-json.MarshalContext(ctx Context, v interface{}, optFuncs ...json.EncodeOptionFunc) ([]byte, error) func github.com/goccy/go-json.UnmarshalContext(ctx Context, data []byte, v interface{}, optFuncs ...json.DecodeOptionFunc) error func github.com/goccy/go-json.(*Decoder).DecodeContext(ctx Context, v interface{}) error func github.com/goccy/go-json.(*Encoder).EncodeContext(ctx Context, v interface{}, optFuncs ...json.EncodeOptionFunc) error func github.com/goccy/go-json.MarshalerContext.MarshalJSON(Context) ([]byte, error) func github.com/goccy/go-json.UnmarshalerContext.UnmarshalJSON(Context, []byte) error func github.com/goccy/go-json/internal/encoder.FieldQueryFromContext(ctx Context) *encoder.FieldQuery func github.com/goccy/go-json/internal/encoder.SetFieldQueryToContext(ctx Context, query *encoder.FieldQuery) Context func github.com/google/go-github/v66/github.NewTokenClient(_ Context, token string) *github.Client func github.com/google/go-github/v66/github.(*ActionsService).AddEnabledOrgInEnterprise(ctx Context, owner string, organizationID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).AddEnabledReposInOrg(ctx Context, owner string, repositoryID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).AddRepositoryAccessRunnerGroup(ctx Context, org string, groupID, repoID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).AddRepoToRequiredWorkflow(ctx Context, org string, requiredWorkflowID, repoID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).AddRunnerGroupRunners(ctx Context, org string, groupID, runnerID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).AddSelectedRepoToOrgSecret(ctx Context, org, name string, repo *github.Repository) (*github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).AddSelectedRepoToOrgVariable(ctx Context, org, name string, repo *github.Repository) (*github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).CancelWorkflowRunByID(ctx Context, owner, repo string, runID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).CreateEnvVariable(ctx Context, owner, repo, env string, variable *github.ActionsVariable) (*github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).CreateOrganizationRegistrationToken(ctx Context, org string) (*github.RegistrationToken, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).CreateOrganizationRemoveToken(ctx Context, org string) (*github.RemoveToken, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).CreateOrganizationRunnerGroup(ctx Context, org string, createReq github.CreateRunnerGroupRequest) (*github.RunnerGroup, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).CreateOrgVariable(ctx Context, org string, variable *github.ActionsVariable) (*github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).CreateOrUpdateEnvSecret(ctx Context, repoID int, env string, eSecret *github.EncryptedSecret) (*github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).CreateOrUpdateOrgSecret(ctx Context, org string, eSecret *github.EncryptedSecret) (*github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).CreateOrUpdateRepoSecret(ctx Context, owner, repo string, eSecret *github.EncryptedSecret) (*github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).CreateRegistrationToken(ctx Context, owner, repo string) (*github.RegistrationToken, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).CreateRemoveToken(ctx Context, owner, repo string) (*github.RemoveToken, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).CreateRepoVariable(ctx Context, owner, repo string, variable *github.ActionsVariable) (*github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).CreateRequiredWorkflow(ctx Context, org string, createRequiredWorkflowOptions *github.CreateUpdateRequiredWorkflowOptions) (*github.OrgRequiredWorkflow, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).CreateWorkflowDispatchEventByFileName(ctx Context, owner, repo, workflowFileName string, event github.CreateWorkflowDispatchEventRequest) (*github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).CreateWorkflowDispatchEventByID(ctx Context, owner, repo string, workflowID int64, event github.CreateWorkflowDispatchEventRequest) (*github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).DeleteArtifact(ctx Context, owner, repo string, artifactID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).DeleteCachesByID(ctx Context, owner, repo string, cacheID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).DeleteCachesByKey(ctx Context, owner, repo, key string, ref *string) (*github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).DeleteEnvSecret(ctx Context, repoID int, env, secretName string) (*github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).DeleteEnvVariable(ctx Context, owner, repo, env, variableName string) (*github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).DeleteOrganizationRunnerGroup(ctx Context, org string, groupID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).DeleteOrgSecret(ctx Context, org, name string) (*github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).DeleteOrgVariable(ctx Context, org, name string) (*github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).DeleteRepoSecret(ctx Context, owner, repo, name string) (*github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).DeleteRepoVariable(ctx Context, owner, repo, name string) (*github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).DeleteRequiredWorkflow(ctx Context, org string, requiredWorkflowID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).DeleteWorkflowRun(ctx Context, owner, repo string, runID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).DeleteWorkflowRunLogs(ctx Context, owner, repo string, runID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).DisableWorkflowByFileName(ctx Context, owner, repo, workflowFileName string) (*github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).DisableWorkflowByID(ctx Context, owner, repo string, workflowID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).DownloadArtifact(ctx Context, owner, repo string, artifactID int64, maxRedirects int) (*url.URL, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).EditActionsAllowed(ctx Context, org string, actionsAllowed github.ActionsAllowed) (*github.ActionsAllowed, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).EditActionsAllowedInEnterprise(ctx Context, enterprise string, actionsAllowed github.ActionsAllowed) (*github.ActionsAllowed, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).EditActionsPermissions(ctx Context, org string, actionsPermissions github.ActionsPermissions) (*github.ActionsPermissions, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).EditActionsPermissionsInEnterprise(ctx Context, enterprise string, actionsPermissionsEnterprise github.ActionsPermissionsEnterprise) (*github.ActionsPermissionsEnterprise, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).EditDefaultWorkflowPermissionsInEnterprise(ctx Context, enterprise string, permissions github.DefaultWorkflowPermissionEnterprise) (*github.DefaultWorkflowPermissionEnterprise, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).EditDefaultWorkflowPermissionsInOrganization(ctx Context, org string, permissions github.DefaultWorkflowPermissionOrganization) (*github.DefaultWorkflowPermissionOrganization, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).EnableWorkflowByFileName(ctx Context, owner, repo, workflowFileName string) (*github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).EnableWorkflowByID(ctx Context, owner, repo string, workflowID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).GenerateOrgJITConfig(ctx Context, org string, request *github.GenerateJITConfigRequest) (*github.JITRunnerConfig, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).GenerateRepoJITConfig(ctx Context, owner, repo string, request *github.GenerateJITConfigRequest) (*github.JITRunnerConfig, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).GetActionsAllowed(ctx Context, org string) (*github.ActionsAllowed, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).GetActionsAllowedInEnterprise(ctx Context, enterprise string) (*github.ActionsAllowed, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).GetActionsPermissions(ctx Context, org string) (*github.ActionsPermissions, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).GetActionsPermissionsInEnterprise(ctx Context, enterprise string) (*github.ActionsPermissionsEnterprise, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).GetArtifact(ctx Context, owner, repo string, artifactID int64) (*github.Artifact, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).GetCacheUsageForRepo(ctx Context, owner, repo string) (*github.ActionsCacheUsage, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).GetDefaultWorkflowPermissionsInEnterprise(ctx Context, enterprise string) (*github.DefaultWorkflowPermissionEnterprise, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).GetDefaultWorkflowPermissionsInOrganization(ctx Context, org string) (*github.DefaultWorkflowPermissionOrganization, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).GetEnvPublicKey(ctx Context, repoID int, env string) (*github.PublicKey, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).GetEnvSecret(ctx Context, repoID int, env, secretName string) (*github.Secret, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).GetEnvVariable(ctx Context, owner, repo, env, variableName string) (*github.ActionsVariable, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).GetOrganizationRunner(ctx Context, org string, runnerID int64) (*github.Runner, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).GetOrganizationRunnerGroup(ctx Context, org string, groupID int64) (*github.RunnerGroup, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).GetOrgOIDCSubjectClaimCustomTemplate(ctx Context, org string) (*github.OIDCSubjectClaimCustomTemplate, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).GetOrgPublicKey(ctx Context, org string) (*github.PublicKey, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).GetOrgSecret(ctx Context, org, name string) (*github.Secret, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).GetOrgVariable(ctx Context, org, name string) (*github.ActionsVariable, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).GetPendingDeployments(ctx Context, owner, repo string, runID int64) ([]*github.PendingDeployment, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).GetRepoOIDCSubjectClaimCustomTemplate(ctx Context, owner, repo string) (*github.OIDCSubjectClaimCustomTemplate, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).GetRepoPublicKey(ctx Context, owner, repo string) (*github.PublicKey, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).GetRepoSecret(ctx Context, owner, repo, name string) (*github.Secret, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).GetRepoVariable(ctx Context, owner, repo, name string) (*github.ActionsVariable, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).GetRequiredWorkflowByID(ctx Context, owner string, requiredWorkflowID int64) (*github.OrgRequiredWorkflow, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).GetRunner(ctx Context, owner, repo string, runnerID int64) (*github.Runner, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).GetTotalCacheUsageForEnterprise(ctx Context, enterprise string) (*github.TotalCacheUsage, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).GetTotalCacheUsageForOrg(ctx Context, org string) (*github.TotalCacheUsage, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).GetWorkflowByFileName(ctx Context, owner, repo, workflowFileName string) (*github.Workflow, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).GetWorkflowByID(ctx Context, owner, repo string, workflowID int64) (*github.Workflow, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).GetWorkflowJobByID(ctx Context, owner, repo string, jobID int64) (*github.WorkflowJob, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).GetWorkflowJobLogs(ctx Context, owner, repo string, jobID int64, maxRedirects int) (*url.URL, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).GetWorkflowRunAttempt(ctx Context, owner, repo string, runID int64, attemptNumber int, opts *github.WorkflowRunAttemptOptions) (*github.WorkflowRun, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).GetWorkflowRunAttemptLogs(ctx Context, owner, repo string, runID int64, attemptNumber int, maxRedirects int) (*url.URL, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).GetWorkflowRunByID(ctx Context, owner, repo string, runID int64) (*github.WorkflowRun, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).GetWorkflowRunLogs(ctx Context, owner, repo string, runID int64, maxRedirects int) (*url.URL, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).GetWorkflowRunUsageByID(ctx Context, owner, repo string, runID int64) (*github.WorkflowRunUsage, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).GetWorkflowUsageByFileName(ctx Context, owner, repo, workflowFileName string) (*github.WorkflowUsage, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).GetWorkflowUsageByID(ctx Context, owner, repo string, workflowID int64) (*github.WorkflowUsage, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).ListArtifacts(ctx Context, owner, repo string, opts *github.ListOptions) (*github.ArtifactList, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).ListCaches(ctx Context, owner, repo string, opts *github.ActionsCacheListOptions) (*github.ActionsCacheList, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).ListCacheUsageByRepoForOrg(ctx Context, org string, opts *github.ListOptions) (*github.ActionsCacheUsageList, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).ListEnabledOrgsInEnterprise(ctx Context, owner string, opts *github.ListOptions) (*github.ActionsEnabledOnEnterpriseRepos, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).ListEnabledReposInOrg(ctx Context, owner string, opts *github.ListOptions) (*github.ActionsEnabledOnOrgRepos, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).ListEnvSecrets(ctx Context, repoID int, env string, opts *github.ListOptions) (*github.Secrets, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).ListEnvVariables(ctx Context, owner, repo, env string, opts *github.ListOptions) (*github.ActionsVariables, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).ListOrganizationRunnerApplicationDownloads(ctx Context, org string) ([]*github.RunnerApplicationDownload, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).ListOrganizationRunnerGroups(ctx Context, org string, opts *github.ListOrgRunnerGroupOptions) (*github.RunnerGroups, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).ListOrganizationRunners(ctx Context, org string, opts *github.ListRunnersOptions) (*github.Runners, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).ListOrgRequiredWorkflows(ctx Context, org string, opts *github.ListOptions) (*github.OrgRequiredWorkflows, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).ListOrgSecrets(ctx Context, org string, opts *github.ListOptions) (*github.Secrets, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).ListOrgVariables(ctx Context, org string, opts *github.ListOptions) (*github.ActionsVariables, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).ListRepoOrgSecrets(ctx Context, owner, repo string, opts *github.ListOptions) (*github.Secrets, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).ListRepoOrgVariables(ctx Context, owner, repo string, opts *github.ListOptions) (*github.ActionsVariables, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).ListRepoRequiredWorkflows(ctx Context, owner, repo string, opts *github.ListOptions) (*github.RepoRequiredWorkflows, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).ListRepoSecrets(ctx Context, owner, repo string, opts *github.ListOptions) (*github.Secrets, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).ListRepositoryAccessRunnerGroup(ctx Context, org string, groupID int64, opts *github.ListOptions) (*github.ListRepositories, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).ListRepositoryWorkflowRuns(ctx Context, owner, repo string, opts *github.ListWorkflowRunsOptions) (*github.WorkflowRuns, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).ListRepoVariables(ctx Context, owner, repo string, opts *github.ListOptions) (*github.ActionsVariables, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).ListRequiredWorkflowSelectedRepos(ctx Context, org string, requiredWorkflowID int64, opts *github.ListOptions) (*github.RequiredWorkflowSelectedRepos, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).ListRunnerApplicationDownloads(ctx Context, owner, repo string) ([]*github.RunnerApplicationDownload, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).ListRunnerGroupRunners(ctx Context, org string, groupID int64, opts *github.ListOptions) (*github.Runners, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).ListRunners(ctx Context, owner, repo string, opts *github.ListRunnersOptions) (*github.Runners, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).ListSelectedReposForOrgSecret(ctx Context, org, name string, opts *github.ListOptions) (*github.SelectedReposList, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).ListSelectedReposForOrgVariable(ctx Context, org, name string, opts *github.ListOptions) (*github.SelectedReposList, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).ListWorkflowJobs(ctx Context, owner, repo string, runID int64, opts *github.ListWorkflowJobsOptions) (*github.Jobs, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).ListWorkflowJobsAttempt(ctx Context, owner, repo string, runID, attemptNumber int64, opts *github.ListOptions) (*github.Jobs, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).ListWorkflowRunArtifacts(ctx Context, owner, repo string, runID int64, opts *github.ListOptions) (*github.ArtifactList, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).ListWorkflowRunsByFileName(ctx Context, owner, repo, workflowFileName string, opts *github.ListWorkflowRunsOptions) (*github.WorkflowRuns, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).ListWorkflowRunsByID(ctx Context, owner, repo string, workflowID int64, opts *github.ListWorkflowRunsOptions) (*github.WorkflowRuns, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).ListWorkflows(ctx Context, owner, repo string, opts *github.ListOptions) (*github.Workflows, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).PendingDeployments(ctx Context, owner, repo string, runID int64, request *github.PendingDeploymentsRequest) ([]*github.Deployment, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).RemoveEnabledOrgInEnterprise(ctx Context, owner string, organizationID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).RemoveEnabledReposInOrg(ctx Context, owner string, repositoryID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).RemoveOrganizationRunner(ctx Context, org string, runnerID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).RemoveRepoFromRequiredWorkflow(ctx Context, org string, requiredWorkflowID, repoID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).RemoveRepositoryAccessRunnerGroup(ctx Context, org string, groupID, repoID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).RemoveRunner(ctx Context, owner, repo string, runnerID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).RemoveRunnerGroupRunners(ctx Context, org string, groupID, runnerID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).RemoveSelectedRepoFromOrgSecret(ctx Context, org, name string, repo *github.Repository) (*github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).RemoveSelectedRepoFromOrgVariable(ctx Context, org, name string, repo *github.Repository) (*github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).RerunFailedJobsByID(ctx Context, owner, repo string, runID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).RerunJobByID(ctx Context, owner, repo string, jobID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).RerunWorkflowByID(ctx Context, owner, repo string, runID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).ReviewCustomDeploymentProtectionRule(ctx Context, owner, repo string, runID int64, request *github.ReviewCustomDeploymentProtectionRuleRequest) (*github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).SetEnabledOrgsInEnterprise(ctx Context, owner string, organizationIDs []int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).SetEnabledReposInOrg(ctx Context, owner string, repositoryIDs []int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).SetOrgOIDCSubjectClaimCustomTemplate(ctx Context, org string, template *github.OIDCSubjectClaimCustomTemplate) (*github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).SetRepoOIDCSubjectClaimCustomTemplate(ctx Context, owner, repo string, template *github.OIDCSubjectClaimCustomTemplate) (*github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).SetRepositoryAccessRunnerGroup(ctx Context, org string, groupID int64, ids github.SetRepoAccessRunnerGroupRequest) (*github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).SetRequiredWorkflowSelectedRepos(ctx Context, org string, requiredWorkflowID int64, ids github.SelectedRepoIDs) (*github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).SetRunnerGroupRunners(ctx Context, org string, groupID int64, ids github.SetRunnerGroupRunnersRequest) (*github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).SetSelectedReposForOrgSecret(ctx Context, org, name string, ids github.SelectedRepoIDs) (*github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).SetSelectedReposForOrgVariable(ctx Context, org, name string, ids github.SelectedRepoIDs) (*github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).UpdateEnvVariable(ctx Context, owner, repo, env string, variable *github.ActionsVariable) (*github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).UpdateOrganizationRunnerGroup(ctx Context, org string, groupID int64, updateReq github.UpdateRunnerGroupRequest) (*github.RunnerGroup, *github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).UpdateOrgVariable(ctx Context, org string, variable *github.ActionsVariable) (*github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).UpdateRepoVariable(ctx Context, owner, repo string, variable *github.ActionsVariable) (*github.Response, error) func github.com/google/go-github/v66/github.(*ActionsService).UpdateRequiredWorkflow(ctx Context, org string, requiredWorkflowID int64, updateRequiredWorkflowOptions *github.CreateUpdateRequiredWorkflowOptions) (*github.OrgRequiredWorkflow, *github.Response, error) func github.com/google/go-github/v66/github.(*ActivityService).DeleteRepositorySubscription(ctx Context, owner, repo string) (*github.Response, error) func github.com/google/go-github/v66/github.(*ActivityService).DeleteThreadSubscription(ctx Context, id string) (*github.Response, error) func github.com/google/go-github/v66/github.(*ActivityService).GetRepositorySubscription(ctx Context, owner, repo string) (*github.Subscription, *github.Response, error) func github.com/google/go-github/v66/github.(*ActivityService).GetThread(ctx Context, id string) (*github.Notification, *github.Response, error) func github.com/google/go-github/v66/github.(*ActivityService).GetThreadSubscription(ctx Context, id string) (*github.Subscription, *github.Response, error) func github.com/google/go-github/v66/github.(*ActivityService).IsStarred(ctx Context, owner, repo string) (bool, *github.Response, error) func github.com/google/go-github/v66/github.(*ActivityService).ListEvents(ctx Context, opts *github.ListOptions) ([]*github.Event, *github.Response, error) func github.com/google/go-github/v66/github.(*ActivityService).ListEventsForOrganization(ctx Context, org string, opts *github.ListOptions) ([]*github.Event, *github.Response, error) func github.com/google/go-github/v66/github.(*ActivityService).ListEventsForRepoNetwork(ctx Context, owner, repo string, opts *github.ListOptions) ([]*github.Event, *github.Response, error) func github.com/google/go-github/v66/github.(*ActivityService).ListEventsPerformedByUser(ctx Context, user string, publicOnly bool, opts *github.ListOptions) ([]*github.Event, *github.Response, error) func github.com/google/go-github/v66/github.(*ActivityService).ListEventsReceivedByUser(ctx Context, user string, publicOnly bool, opts *github.ListOptions) ([]*github.Event, *github.Response, error) func github.com/google/go-github/v66/github.(*ActivityService).ListFeeds(ctx Context) (*github.Feeds, *github.Response, error) func github.com/google/go-github/v66/github.(*ActivityService).ListIssueEventsForRepository(ctx Context, owner, repo string, opts *github.ListOptions) ([]*github.IssueEvent, *github.Response, error) func github.com/google/go-github/v66/github.(*ActivityService).ListNotifications(ctx Context, opts *github.NotificationListOptions) ([]*github.Notification, *github.Response, error) func github.com/google/go-github/v66/github.(*ActivityService).ListRepositoryEvents(ctx Context, owner, repo string, opts *github.ListOptions) ([]*github.Event, *github.Response, error) func github.com/google/go-github/v66/github.(*ActivityService).ListRepositoryNotifications(ctx Context, owner, repo string, opts *github.NotificationListOptions) ([]*github.Notification, *github.Response, error) func github.com/google/go-github/v66/github.(*ActivityService).ListStargazers(ctx Context, owner, repo string, opts *github.ListOptions) ([]*github.Stargazer, *github.Response, error) func github.com/google/go-github/v66/github.(*ActivityService).ListStarred(ctx Context, user string, opts *github.ActivityListStarredOptions) ([]*github.StarredRepository, *github.Response, error) func github.com/google/go-github/v66/github.(*ActivityService).ListUserEventsForOrganization(ctx Context, org, user string, opts *github.ListOptions) ([]*github.Event, *github.Response, error) func github.com/google/go-github/v66/github.(*ActivityService).ListWatched(ctx Context, user string, opts *github.ListOptions) ([]*github.Repository, *github.Response, error) func github.com/google/go-github/v66/github.(*ActivityService).ListWatchers(ctx Context, owner, repo string, opts *github.ListOptions) ([]*github.User, *github.Response, error) func github.com/google/go-github/v66/github.(*ActivityService).MarkNotificationsRead(ctx Context, lastRead github.Timestamp) (*github.Response, error) func github.com/google/go-github/v66/github.(*ActivityService).MarkRepositoryNotificationsRead(ctx Context, owner, repo string, lastRead github.Timestamp) (*github.Response, error) func github.com/google/go-github/v66/github.(*ActivityService).MarkThreadDone(ctx Context, id int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*ActivityService).MarkThreadRead(ctx Context, id string) (*github.Response, error) func github.com/google/go-github/v66/github.(*ActivityService).SetRepositorySubscription(ctx Context, owner, repo string, subscription *github.Subscription) (*github.Subscription, *github.Response, error) func github.com/google/go-github/v66/github.(*ActivityService).SetThreadSubscription(ctx Context, id string, subscription *github.Subscription) (*github.Subscription, *github.Response, error) func github.com/google/go-github/v66/github.(*ActivityService).Star(ctx Context, owner, repo string) (*github.Response, error) func github.com/google/go-github/v66/github.(*ActivityService).Unstar(ctx Context, owner, repo string) (*github.Response, error) func github.com/google/go-github/v66/github.(*AdminService).CreateOrg(ctx Context, org *github.Organization, admin string) (*github.Organization, *github.Response, error) func github.com/google/go-github/v66/github.(*AdminService).CreateUser(ctx Context, userReq github.CreateUserRequest) (*github.User, *github.Response, error) func github.com/google/go-github/v66/github.(*AdminService).CreateUserImpersonation(ctx Context, username string, opts *github.ImpersonateUserOptions) (*github.UserAuthorization, *github.Response, error) func github.com/google/go-github/v66/github.(*AdminService).DeleteUser(ctx Context, username string) (*github.Response, error) func github.com/google/go-github/v66/github.(*AdminService).DeleteUserImpersonation(ctx Context, username string) (*github.Response, error) func github.com/google/go-github/v66/github.(*AdminService).GetAdminStats(ctx Context) (*github.AdminStats, *github.Response, error) func github.com/google/go-github/v66/github.(*AdminService).RenameOrg(ctx Context, org *github.Organization, newName string) (*github.RenameOrgResponse, *github.Response, error) func github.com/google/go-github/v66/github.(*AdminService).RenameOrgByName(ctx Context, org, newName string) (*github.RenameOrgResponse, *github.Response, error) func github.com/google/go-github/v66/github.(*AdminService).UpdateTeamLDAPMapping(ctx Context, team int64, mapping *github.TeamLDAPMapping) (*github.TeamLDAPMapping, *github.Response, error) func github.com/google/go-github/v66/github.(*AdminService).UpdateUserLDAPMapping(ctx Context, user string, mapping *github.UserLDAPMapping) (*github.UserLDAPMapping, *github.Response, error) func github.com/google/go-github/v66/github.(*AppsService).AddRepository(ctx Context, instID, repoID int64) (*github.Repository, *github.Response, error) func github.com/google/go-github/v66/github.(*AppsService).CompleteAppManifest(ctx Context, code string) (*github.AppConfig, *github.Response, error) func github.com/google/go-github/v66/github.(*AppsService).CreateAttachment(ctx Context, contentReferenceID int64, title, body string) (*github.Attachment, *github.Response, error) func github.com/google/go-github/v66/github.(*AppsService).CreateInstallationToken(ctx Context, id int64, opts *github.InstallationTokenOptions) (*github.InstallationToken, *github.Response, error) func github.com/google/go-github/v66/github.(*AppsService).CreateInstallationTokenListRepos(ctx Context, id int64, opts *github.InstallationTokenListRepoOptions) (*github.InstallationToken, *github.Response, error) func github.com/google/go-github/v66/github.(*AppsService).DeleteInstallation(ctx Context, id int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*AppsService).FindOrganizationInstallation(ctx Context, org string) (*github.Installation, *github.Response, error) func github.com/google/go-github/v66/github.(*AppsService).FindRepositoryInstallation(ctx Context, owner, repo string) (*github.Installation, *github.Response, error) func github.com/google/go-github/v66/github.(*AppsService).FindRepositoryInstallationByID(ctx Context, id int64) (*github.Installation, *github.Response, error) func github.com/google/go-github/v66/github.(*AppsService).FindUserInstallation(ctx Context, user string) (*github.Installation, *github.Response, error) func github.com/google/go-github/v66/github.(*AppsService).Get(ctx Context, appSlug string) (*github.App, *github.Response, error) func github.com/google/go-github/v66/github.(*AppsService).GetHookConfig(ctx Context) (*github.HookConfig, *github.Response, error) func github.com/google/go-github/v66/github.(*AppsService).GetHookDelivery(ctx Context, deliveryID int64) (*github.HookDelivery, *github.Response, error) func github.com/google/go-github/v66/github.(*AppsService).GetInstallation(ctx Context, id int64) (*github.Installation, *github.Response, error) func github.com/google/go-github/v66/github.(*AppsService).ListHookDeliveries(ctx Context, opts *github.ListCursorOptions) ([]*github.HookDelivery, *github.Response, error) func github.com/google/go-github/v66/github.(*AppsService).ListInstallationRequests(ctx Context, opts *github.ListOptions) ([]*github.InstallationRequest, *github.Response, error) func github.com/google/go-github/v66/github.(*AppsService).ListInstallations(ctx Context, opts *github.ListOptions) ([]*github.Installation, *github.Response, error) func github.com/google/go-github/v66/github.(*AppsService).ListRepos(ctx Context, opts *github.ListOptions) (*github.ListRepositories, *github.Response, error) func github.com/google/go-github/v66/github.(*AppsService).ListUserInstallations(ctx Context, opts *github.ListOptions) ([]*github.Installation, *github.Response, error) func github.com/google/go-github/v66/github.(*AppsService).ListUserRepos(ctx Context, id int64, opts *github.ListOptions) (*github.ListRepositories, *github.Response, error) func github.com/google/go-github/v66/github.(*AppsService).RedeliverHookDelivery(ctx Context, deliveryID int64) (*github.HookDelivery, *github.Response, error) func github.com/google/go-github/v66/github.(*AppsService).RemoveRepository(ctx Context, instID, repoID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*AppsService).RevokeInstallationToken(ctx Context) (*github.Response, error) func github.com/google/go-github/v66/github.(*AppsService).SuspendInstallation(ctx Context, id int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*AppsService).UnsuspendInstallation(ctx Context, id int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*AppsService).UpdateHookConfig(ctx Context, config *github.HookConfig) (*github.HookConfig, *github.Response, error) func github.com/google/go-github/v66/github.(*AuthorizationsService).Check(ctx Context, clientID, accessToken string) (*github.Authorization, *github.Response, error) func github.com/google/go-github/v66/github.(*AuthorizationsService).CreateImpersonation(ctx Context, username string, authReq *github.AuthorizationRequest) (*github.Authorization, *github.Response, error) func github.com/google/go-github/v66/github.(*AuthorizationsService).DeleteGrant(ctx Context, clientID, accessToken string) (*github.Response, error) func github.com/google/go-github/v66/github.(*AuthorizationsService).DeleteImpersonation(ctx Context, username string) (*github.Response, error) func github.com/google/go-github/v66/github.(*AuthorizationsService).Reset(ctx Context, clientID, accessToken string) (*github.Authorization, *github.Response, error) func github.com/google/go-github/v66/github.(*AuthorizationsService).Revoke(ctx Context, clientID, accessToken string) (*github.Response, error) func github.com/google/go-github/v66/github.(*BillingService).GetActionsBillingOrg(ctx Context, org string) (*github.ActionBilling, *github.Response, error) func github.com/google/go-github/v66/github.(*BillingService).GetActionsBillingUser(ctx Context, user string) (*github.ActionBilling, *github.Response, error) func github.com/google/go-github/v66/github.(*BillingService).GetAdvancedSecurityActiveCommittersOrg(ctx Context, org string, opts *github.ListOptions) (*github.ActiveCommitters, *github.Response, error) func github.com/google/go-github/v66/github.(*BillingService).GetPackagesBillingOrg(ctx Context, org string) (*github.PackageBilling, *github.Response, error) func github.com/google/go-github/v66/github.(*BillingService).GetPackagesBillingUser(ctx Context, user string) (*github.PackageBilling, *github.Response, error) func github.com/google/go-github/v66/github.(*BillingService).GetStorageBillingOrg(ctx Context, org string) (*github.StorageBilling, *github.Response, error) func github.com/google/go-github/v66/github.(*BillingService).GetStorageBillingUser(ctx Context, user string) (*github.StorageBilling, *github.Response, error) func github.com/google/go-github/v66/github.(*ChecksService).CreateCheckRun(ctx Context, owner, repo string, opts github.CreateCheckRunOptions) (*github.CheckRun, *github.Response, error) func github.com/google/go-github/v66/github.(*ChecksService).CreateCheckSuite(ctx Context, owner, repo string, opts github.CreateCheckSuiteOptions) (*github.CheckSuite, *github.Response, error) func github.com/google/go-github/v66/github.(*ChecksService).GetCheckRun(ctx Context, owner, repo string, checkRunID int64) (*github.CheckRun, *github.Response, error) func github.com/google/go-github/v66/github.(*ChecksService).GetCheckSuite(ctx Context, owner, repo string, checkSuiteID int64) (*github.CheckSuite, *github.Response, error) func github.com/google/go-github/v66/github.(*ChecksService).ListCheckRunAnnotations(ctx Context, owner, repo string, checkRunID int64, opts *github.ListOptions) ([]*github.CheckRunAnnotation, *github.Response, error) func github.com/google/go-github/v66/github.(*ChecksService).ListCheckRunsCheckSuite(ctx Context, owner, repo string, checkSuiteID int64, opts *github.ListCheckRunsOptions) (*github.ListCheckRunsResults, *github.Response, error) func github.com/google/go-github/v66/github.(*ChecksService).ListCheckRunsForRef(ctx Context, owner, repo, ref string, opts *github.ListCheckRunsOptions) (*github.ListCheckRunsResults, *github.Response, error) func github.com/google/go-github/v66/github.(*ChecksService).ListCheckSuitesForRef(ctx Context, owner, repo, ref string, opts *github.ListCheckSuiteOptions) (*github.ListCheckSuiteResults, *github.Response, error) func github.com/google/go-github/v66/github.(*ChecksService).ReRequestCheckRun(ctx Context, owner, repo string, checkRunID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*ChecksService).ReRequestCheckSuite(ctx Context, owner, repo string, checkSuiteID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*ChecksService).SetCheckSuitePreferences(ctx Context, owner, repo string, opts github.CheckSuitePreferenceOptions) (*github.CheckSuitePreferenceResults, *github.Response, error) func github.com/google/go-github/v66/github.(*ChecksService).UpdateCheckRun(ctx Context, owner, repo string, checkRunID int64, opts github.UpdateCheckRunOptions) (*github.CheckRun, *github.Response, error) func github.com/google/go-github/v66/github.(*Client).APIMeta(ctx Context) (*github.APIMeta, *github.Response, error) func github.com/google/go-github/v66/github.(*Client).BareDo(ctx Context, req *http.Request) (*github.Response, error) func github.com/google/go-github/v66/github.(*Client).Do(ctx Context, req *http.Request, v interface{}) (*github.Response, error) func github.com/google/go-github/v66/github.(*Client).GetCodeOfConduct(ctx Context, key string) (*github.CodeOfConduct, *github.Response, error) func github.com/google/go-github/v66/github.(*Client).ListCodesOfConduct(ctx Context) ([]*github.CodeOfConduct, *github.Response, error) func github.com/google/go-github/v66/github.(*Client).ListEmojis(ctx Context) (map[string]string, *github.Response, error) func github.com/google/go-github/v66/github.(*Client).Octocat(ctx Context, message string) (string, *github.Response, error) func github.com/google/go-github/v66/github.(*Client).RateLimits(ctx Context) (*github.RateLimits, *github.Response, error) func github.com/google/go-github/v66/github.(*Client).Zen(ctx Context) (string, *github.Response, error) func github.com/google/go-github/v66/github.(*CodeScanningService).DeleteAnalysis(ctx Context, owner, repo string, id int64) (*github.DeleteAnalysis, *github.Response, error) func github.com/google/go-github/v66/github.(*CodeScanningService).GetAlert(ctx Context, owner, repo string, id int64) (*github.Alert, *github.Response, error) func github.com/google/go-github/v66/github.(*CodeScanningService).GetAnalysis(ctx Context, owner, repo string, id int64) (*github.ScanningAnalysis, *github.Response, error) func github.com/google/go-github/v66/github.(*CodeScanningService).GetCodeQLDatabase(ctx Context, owner, repo, language string) (*github.CodeQLDatabase, *github.Response, error) func github.com/google/go-github/v66/github.(*CodeScanningService).GetDefaultSetupConfiguration(ctx Context, owner, repo string) (*github.DefaultSetupConfiguration, *github.Response, error) func github.com/google/go-github/v66/github.(*CodeScanningService).GetSARIF(ctx Context, owner, repo, sarifID string) (*github.SARIFUpload, *github.Response, error) func github.com/google/go-github/v66/github.(*CodeScanningService).ListAlertInstances(ctx Context, owner, repo string, id int64, opts *github.AlertInstancesListOptions) ([]*github.MostRecentInstance, *github.Response, error) func github.com/google/go-github/v66/github.(*CodeScanningService).ListAlertsForOrg(ctx Context, org string, opts *github.AlertListOptions) ([]*github.Alert, *github.Response, error) func github.com/google/go-github/v66/github.(*CodeScanningService).ListAlertsForRepo(ctx Context, owner, repo string, opts *github.AlertListOptions) ([]*github.Alert, *github.Response, error) func github.com/google/go-github/v66/github.(*CodeScanningService).ListAnalysesForRepo(ctx Context, owner, repo string, opts *github.AnalysesListOptions) ([]*github.ScanningAnalysis, *github.Response, error) func github.com/google/go-github/v66/github.(*CodeScanningService).ListCodeQLDatabases(ctx Context, owner, repo string) ([]*github.CodeQLDatabase, *github.Response, error) func github.com/google/go-github/v66/github.(*CodeScanningService).UpdateAlert(ctx Context, owner, repo string, id int64, stateInfo *github.CodeScanningAlertState) (*github.Alert, *github.Response, error) func github.com/google/go-github/v66/github.(*CodeScanningService).UpdateDefaultSetupConfiguration(ctx Context, owner, repo string, options *github.UpdateDefaultSetupConfigurationOptions) (*github.UpdateDefaultSetupConfigurationResponse, *github.Response, error) func github.com/google/go-github/v66/github.(*CodeScanningService).UploadSarif(ctx Context, owner, repo string, sarif *github.SarifAnalysis) (*github.SarifID, *github.Response, error) func github.com/google/go-github/v66/github.(*CodesOfConductService).Get(ctx Context, key string) (*github.CodeOfConduct, *github.Response, error) func github.com/google/go-github/v66/github.(*CodesOfConductService).List(ctx Context) ([]*github.CodeOfConduct, *github.Response, error) func github.com/google/go-github/v66/github.(*CodespacesService).AddSelectedRepoToOrgSecret(ctx Context, org, name string, repo *github.Repository) (*github.Response, error) func github.com/google/go-github/v66/github.(*CodespacesService).AddSelectedRepoToUserSecret(ctx Context, name string, repo *github.Repository) (*github.Response, error) func github.com/google/go-github/v66/github.(*CodespacesService).CreateInRepo(ctx Context, owner, repo string, request *github.CreateCodespaceOptions) (*github.Codespace, *github.Response, error) func github.com/google/go-github/v66/github.(*CodespacesService).CreateOrUpdateOrgSecret(ctx Context, org string, eSecret *github.EncryptedSecret) (*github.Response, error) func github.com/google/go-github/v66/github.(*CodespacesService).CreateOrUpdateRepoSecret(ctx Context, owner, repo string, eSecret *github.EncryptedSecret) (*github.Response, error) func github.com/google/go-github/v66/github.(*CodespacesService).CreateOrUpdateUserSecret(ctx Context, eSecret *github.EncryptedSecret) (*github.Response, error) func github.com/google/go-github/v66/github.(*CodespacesService).Delete(ctx Context, codespaceName string) (*github.Response, error) func github.com/google/go-github/v66/github.(*CodespacesService).DeleteOrgSecret(ctx Context, org, name string) (*github.Response, error) func github.com/google/go-github/v66/github.(*CodespacesService).DeleteRepoSecret(ctx Context, owner, repo, name string) (*github.Response, error) func github.com/google/go-github/v66/github.(*CodespacesService).DeleteUserSecret(ctx Context, name string) (*github.Response, error) func github.com/google/go-github/v66/github.(*CodespacesService).GetOrgPublicKey(ctx Context, org string) (*github.PublicKey, *github.Response, error) func github.com/google/go-github/v66/github.(*CodespacesService).GetOrgSecret(ctx Context, org, name string) (*github.Secret, *github.Response, error) func github.com/google/go-github/v66/github.(*CodespacesService).GetRepoPublicKey(ctx Context, owner, repo string) (*github.PublicKey, *github.Response, error) func github.com/google/go-github/v66/github.(*CodespacesService).GetRepoSecret(ctx Context, owner, repo, name string) (*github.Secret, *github.Response, error) func github.com/google/go-github/v66/github.(*CodespacesService).GetUserPublicKey(ctx Context) (*github.PublicKey, *github.Response, error) func github.com/google/go-github/v66/github.(*CodespacesService).GetUserSecret(ctx Context, name string) (*github.Secret, *github.Response, error) func github.com/google/go-github/v66/github.(*CodespacesService).List(ctx Context, opts *github.ListCodespacesOptions) (*github.ListCodespaces, *github.Response, error) func github.com/google/go-github/v66/github.(*CodespacesService).ListInRepo(ctx Context, owner, repo string, opts *github.ListOptions) (*github.ListCodespaces, *github.Response, error) func github.com/google/go-github/v66/github.(*CodespacesService).ListOrgSecrets(ctx Context, org string, opts *github.ListOptions) (*github.Secrets, *github.Response, error) func github.com/google/go-github/v66/github.(*CodespacesService).ListRepoSecrets(ctx Context, owner, repo string, opts *github.ListOptions) (*github.Secrets, *github.Response, error) func github.com/google/go-github/v66/github.(*CodespacesService).ListSelectedReposForOrgSecret(ctx Context, org, name string, opts *github.ListOptions) (*github.SelectedReposList, *github.Response, error) func github.com/google/go-github/v66/github.(*CodespacesService).ListSelectedReposForUserSecret(ctx Context, name string, opts *github.ListOptions) (*github.SelectedReposList, *github.Response, error) func github.com/google/go-github/v66/github.(*CodespacesService).ListUserSecrets(ctx Context, opts *github.ListOptions) (*github.Secrets, *github.Response, error) func github.com/google/go-github/v66/github.(*CodespacesService).RemoveSelectedRepoFromOrgSecret(ctx Context, org, name string, repo *github.Repository) (*github.Response, error) func github.com/google/go-github/v66/github.(*CodespacesService).RemoveSelectedRepoFromUserSecret(ctx Context, name string, repo *github.Repository) (*github.Response, error) func github.com/google/go-github/v66/github.(*CodespacesService).SetSelectedReposForOrgSecret(ctx Context, org, name string, ids github.SelectedRepoIDs) (*github.Response, error) func github.com/google/go-github/v66/github.(*CodespacesService).SetSelectedReposForUserSecret(ctx Context, name string, ids github.SelectedRepoIDs) (*github.Response, error) func github.com/google/go-github/v66/github.(*CodespacesService).Start(ctx Context, codespaceName string) (*github.Codespace, *github.Response, error) func github.com/google/go-github/v66/github.(*CodespacesService).Stop(ctx Context, codespaceName string) (*github.Codespace, *github.Response, error) func github.com/google/go-github/v66/github.(*CopilotService).AddCopilotTeams(ctx Context, org string, teamNames []string) (*github.SeatAssignments, *github.Response, error) func github.com/google/go-github/v66/github.(*CopilotService).AddCopilotUsers(ctx Context, org string, users []string) (*github.SeatAssignments, *github.Response, error) func github.com/google/go-github/v66/github.(*CopilotService).GetCopilotBilling(ctx Context, org string) (*github.CopilotOrganizationDetails, *github.Response, error) func github.com/google/go-github/v66/github.(*CopilotService).GetSeatDetails(ctx Context, org, user string) (*github.CopilotSeatDetails, *github.Response, error) func github.com/google/go-github/v66/github.(*CopilotService).ListCopilotSeats(ctx Context, org string, opts *github.ListOptions) (*github.ListCopilotSeatsResponse, *github.Response, error) func github.com/google/go-github/v66/github.(*CopilotService).RemoveCopilotTeams(ctx Context, org string, teamNames []string) (*github.SeatCancellations, *github.Response, error) func github.com/google/go-github/v66/github.(*CopilotService).RemoveCopilotUsers(ctx Context, org string, users []string) (*github.SeatCancellations, *github.Response, error) func github.com/google/go-github/v66/github.(*DependabotService).AddSelectedRepoToOrgSecret(ctx Context, org, name string, repo *github.Repository) (*github.Response, error) func github.com/google/go-github/v66/github.(*DependabotService).CreateOrUpdateOrgSecret(ctx Context, org string, eSecret *github.DependabotEncryptedSecret) (*github.Response, error) func github.com/google/go-github/v66/github.(*DependabotService).CreateOrUpdateRepoSecret(ctx Context, owner, repo string, eSecret *github.DependabotEncryptedSecret) (*github.Response, error) func github.com/google/go-github/v66/github.(*DependabotService).DeleteOrgSecret(ctx Context, org, name string) (*github.Response, error) func github.com/google/go-github/v66/github.(*DependabotService).DeleteRepoSecret(ctx Context, owner, repo, name string) (*github.Response, error) func github.com/google/go-github/v66/github.(*DependabotService).GetOrgPublicKey(ctx Context, org string) (*github.PublicKey, *github.Response, error) func github.com/google/go-github/v66/github.(*DependabotService).GetOrgSecret(ctx Context, org, name string) (*github.Secret, *github.Response, error) func github.com/google/go-github/v66/github.(*DependabotService).GetRepoAlert(ctx Context, owner, repo string, number int) (*github.DependabotAlert, *github.Response, error) func github.com/google/go-github/v66/github.(*DependabotService).GetRepoPublicKey(ctx Context, owner, repo string) (*github.PublicKey, *github.Response, error) func github.com/google/go-github/v66/github.(*DependabotService).GetRepoSecret(ctx Context, owner, repo, name string) (*github.Secret, *github.Response, error) func github.com/google/go-github/v66/github.(*DependabotService).ListOrgAlerts(ctx Context, org string, opts *github.ListAlertsOptions) ([]*github.DependabotAlert, *github.Response, error) func github.com/google/go-github/v66/github.(*DependabotService).ListOrgSecrets(ctx Context, org string, opts *github.ListOptions) (*github.Secrets, *github.Response, error) func github.com/google/go-github/v66/github.(*DependabotService).ListRepoAlerts(ctx Context, owner, repo string, opts *github.ListAlertsOptions) ([]*github.DependabotAlert, *github.Response, error) func github.com/google/go-github/v66/github.(*DependabotService).ListRepoSecrets(ctx Context, owner, repo string, opts *github.ListOptions) (*github.Secrets, *github.Response, error) func github.com/google/go-github/v66/github.(*DependabotService).ListSelectedReposForOrgSecret(ctx Context, org, name string, opts *github.ListOptions) (*github.SelectedReposList, *github.Response, error) func github.com/google/go-github/v66/github.(*DependabotService).RemoveSelectedRepoFromOrgSecret(ctx Context, org, name string, repo *github.Repository) (*github.Response, error) func github.com/google/go-github/v66/github.(*DependabotService).SetSelectedReposForOrgSecret(ctx Context, org, name string, ids github.DependabotSecretsSelectedRepoIDs) (*github.Response, error) func github.com/google/go-github/v66/github.(*DependabotService).UpdateAlert(ctx Context, owner, repo string, number int, stateInfo *github.DependabotAlertState) (*github.DependabotAlert, *github.Response, error) func github.com/google/go-github/v66/github.(*DependencyGraphService).CreateSnapshot(ctx Context, owner, repo string, dependencyGraphSnapshot *github.DependencyGraphSnapshot) (*github.DependencyGraphSnapshotCreationData, *github.Response, error) func github.com/google/go-github/v66/github.(*DependencyGraphService).GetSBOM(ctx Context, owner, repo string) (*github.SBOM, *github.Response, error) func github.com/google/go-github/v66/github.(*EmojisService).List(ctx Context) (map[string]string, *github.Response, error) func github.com/google/go-github/v66/github.(*EnterpriseService).AddOrganizationAccessRunnerGroup(ctx Context, enterprise string, groupID, orgID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*EnterpriseService).AddRunnerGroupRunners(ctx Context, enterprise string, groupID, runnerID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*EnterpriseService).CreateEnterpriseRunnerGroup(ctx Context, enterprise string, createReq github.CreateEnterpriseRunnerGroupRequest) (*github.EnterpriseRunnerGroup, *github.Response, error) func github.com/google/go-github/v66/github.(*EnterpriseService).CreateRegistrationToken(ctx Context, enterprise string) (*github.RegistrationToken, *github.Response, error) func github.com/google/go-github/v66/github.(*EnterpriseService).DeleteEnterpriseRunnerGroup(ctx Context, enterprise string, groupID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*EnterpriseService).EnableDisableSecurityFeature(ctx Context, enterprise, securityProduct, enablement string) (*github.Response, error) func github.com/google/go-github/v66/github.(*EnterpriseService).GenerateEnterpriseJITConfig(ctx Context, enterprise string, request *github.GenerateJITConfigRequest) (*github.JITRunnerConfig, *github.Response, error) func github.com/google/go-github/v66/github.(*EnterpriseService).GetAuditLog(ctx Context, enterprise string, opts *github.GetAuditLogOptions) ([]*github.AuditEntry, *github.Response, error) func github.com/google/go-github/v66/github.(*EnterpriseService).GetCodeSecurityAndAnalysis(ctx Context, enterprise string) (*github.EnterpriseSecurityAnalysisSettings, *github.Response, error) func github.com/google/go-github/v66/github.(*EnterpriseService).GetEnterpriseRunnerGroup(ctx Context, enterprise string, groupID int64) (*github.EnterpriseRunnerGroup, *github.Response, error) func github.com/google/go-github/v66/github.(*EnterpriseService).GetRunner(ctx Context, enterprise string, runnerID int64) (*github.Runner, *github.Response, error) func github.com/google/go-github/v66/github.(*EnterpriseService).ListOrganizationAccessRunnerGroup(ctx Context, enterprise string, groupID int64, opts *github.ListOptions) (*github.ListOrganizations, *github.Response, error) func github.com/google/go-github/v66/github.(*EnterpriseService).ListRunnerApplicationDownloads(ctx Context, enterprise string) ([]*github.RunnerApplicationDownload, *github.Response, error) func github.com/google/go-github/v66/github.(*EnterpriseService).ListRunnerGroupRunners(ctx Context, enterprise string, groupID int64, opts *github.ListOptions) (*github.Runners, *github.Response, error) func github.com/google/go-github/v66/github.(*EnterpriseService).ListRunnerGroups(ctx Context, enterprise string, opts *github.ListEnterpriseRunnerGroupOptions) (*github.EnterpriseRunnerGroups, *github.Response, error) func github.com/google/go-github/v66/github.(*EnterpriseService).ListRunners(ctx Context, enterprise string, opts *github.ListRunnersOptions) (*github.Runners, *github.Response, error) func github.com/google/go-github/v66/github.(*EnterpriseService).RemoveOrganizationAccessRunnerGroup(ctx Context, enterprise string, groupID, orgID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*EnterpriseService).RemoveRunner(ctx Context, enterprise string, runnerID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*EnterpriseService).RemoveRunnerGroupRunners(ctx Context, enterprise string, groupID, runnerID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*EnterpriseService).SetOrganizationAccessRunnerGroup(ctx Context, enterprise string, groupID int64, ids github.SetOrgAccessRunnerGroupRequest) (*github.Response, error) func github.com/google/go-github/v66/github.(*EnterpriseService).SetRunnerGroupRunners(ctx Context, enterprise string, groupID int64, ids github.SetRunnerGroupRunnersRequest) (*github.Response, error) func github.com/google/go-github/v66/github.(*EnterpriseService).UpdateCodeSecurityAndAnalysis(ctx Context, enterprise string, settings *github.EnterpriseSecurityAnalysisSettings) (*github.Response, error) func github.com/google/go-github/v66/github.(*EnterpriseService).UpdateEnterpriseRunnerGroup(ctx Context, enterprise string, groupID int64, updateReq github.UpdateEnterpriseRunnerGroupRequest) (*github.EnterpriseRunnerGroup, *github.Response, error) func github.com/google/go-github/v66/github.(*GistsService).Create(ctx Context, gist *github.Gist) (*github.Gist, *github.Response, error) func github.com/google/go-github/v66/github.(*GistsService).CreateComment(ctx Context, gistID string, comment *github.GistComment) (*github.GistComment, *github.Response, error) func github.com/google/go-github/v66/github.(*GistsService).Delete(ctx Context, id string) (*github.Response, error) func github.com/google/go-github/v66/github.(*GistsService).DeleteComment(ctx Context, gistID string, commentID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*GistsService).Edit(ctx Context, id string, gist *github.Gist) (*github.Gist, *github.Response, error) func github.com/google/go-github/v66/github.(*GistsService).EditComment(ctx Context, gistID string, commentID int64, comment *github.GistComment) (*github.GistComment, *github.Response, error) func github.com/google/go-github/v66/github.(*GistsService).Fork(ctx Context, id string) (*github.Gist, *github.Response, error) func github.com/google/go-github/v66/github.(*GistsService).Get(ctx Context, id string) (*github.Gist, *github.Response, error) func github.com/google/go-github/v66/github.(*GistsService).GetComment(ctx Context, gistID string, commentID int64) (*github.GistComment, *github.Response, error) func github.com/google/go-github/v66/github.(*GistsService).GetRevision(ctx Context, id, sha string) (*github.Gist, *github.Response, error) func github.com/google/go-github/v66/github.(*GistsService).IsStarred(ctx Context, id string) (bool, *github.Response, error) func github.com/google/go-github/v66/github.(*GistsService).List(ctx Context, user string, opts *github.GistListOptions) ([]*github.Gist, *github.Response, error) func github.com/google/go-github/v66/github.(*GistsService).ListAll(ctx Context, opts *github.GistListOptions) ([]*github.Gist, *github.Response, error) func github.com/google/go-github/v66/github.(*GistsService).ListComments(ctx Context, gistID string, opts *github.ListOptions) ([]*github.GistComment, *github.Response, error) func github.com/google/go-github/v66/github.(*GistsService).ListCommits(ctx Context, id string, opts *github.ListOptions) ([]*github.GistCommit, *github.Response, error) func github.com/google/go-github/v66/github.(*GistsService).ListForks(ctx Context, id string, opts *github.ListOptions) ([]*github.GistFork, *github.Response, error) func github.com/google/go-github/v66/github.(*GistsService).ListStarred(ctx Context, opts *github.GistListOptions) ([]*github.Gist, *github.Response, error) func github.com/google/go-github/v66/github.(*GistsService).Star(ctx Context, id string) (*github.Response, error) func github.com/google/go-github/v66/github.(*GistsService).Unstar(ctx Context, id string) (*github.Response, error) func github.com/google/go-github/v66/github.(*GitignoresService).Get(ctx Context, name string) (*github.Gitignore, *github.Response, error) func github.com/google/go-github/v66/github.(*GitignoresService).List(ctx Context) ([]string, *github.Response, error) func github.com/google/go-github/v66/github.(*GitService).CreateBlob(ctx Context, owner string, repo string, blob *github.Blob) (*github.Blob, *github.Response, error) func github.com/google/go-github/v66/github.(*GitService).CreateCommit(ctx Context, owner string, repo string, commit *github.Commit, opts *github.CreateCommitOptions) (*github.Commit, *github.Response, error) func github.com/google/go-github/v66/github.(*GitService).CreateRef(ctx Context, owner string, repo string, ref *github.Reference) (*github.Reference, *github.Response, error) func github.com/google/go-github/v66/github.(*GitService).CreateTag(ctx Context, owner string, repo string, tag *github.Tag) (*github.Tag, *github.Response, error) func github.com/google/go-github/v66/github.(*GitService).CreateTree(ctx Context, owner string, repo string, baseTree string, entries []*github.TreeEntry) (*github.Tree, *github.Response, error) func github.com/google/go-github/v66/github.(*GitService).DeleteRef(ctx Context, owner string, repo string, ref string) (*github.Response, error) func github.com/google/go-github/v66/github.(*GitService).GetBlob(ctx Context, owner string, repo string, sha string) (*github.Blob, *github.Response, error) func github.com/google/go-github/v66/github.(*GitService).GetBlobRaw(ctx Context, owner, repo, sha string) ([]byte, *github.Response, error) func github.com/google/go-github/v66/github.(*GitService).GetCommit(ctx Context, owner string, repo string, sha string) (*github.Commit, *github.Response, error) func github.com/google/go-github/v66/github.(*GitService).GetRef(ctx Context, owner string, repo string, ref string) (*github.Reference, *github.Response, error) func github.com/google/go-github/v66/github.(*GitService).GetTag(ctx Context, owner string, repo string, sha string) (*github.Tag, *github.Response, error) func github.com/google/go-github/v66/github.(*GitService).GetTree(ctx Context, owner string, repo string, sha string, recursive bool) (*github.Tree, *github.Response, error) func github.com/google/go-github/v66/github.(*GitService).ListMatchingRefs(ctx Context, owner, repo string, opts *github.ReferenceListOptions) ([]*github.Reference, *github.Response, error) func github.com/google/go-github/v66/github.(*GitService).UpdateRef(ctx Context, owner string, repo string, ref *github.Reference, force bool) (*github.Reference, *github.Response, error) func github.com/google/go-github/v66/github.(*InteractionsService).GetRestrictionsForOrg(ctx Context, organization string) (*github.InteractionRestriction, *github.Response, error) func github.com/google/go-github/v66/github.(*InteractionsService).GetRestrictionsForRepo(ctx Context, owner, repo string) (*github.InteractionRestriction, *github.Response, error) func github.com/google/go-github/v66/github.(*InteractionsService).RemoveRestrictionsFromOrg(ctx Context, organization string) (*github.Response, error) func github.com/google/go-github/v66/github.(*InteractionsService).RemoveRestrictionsFromRepo(ctx Context, owner, repo string) (*github.Response, error) func github.com/google/go-github/v66/github.(*InteractionsService).UpdateRestrictionsForOrg(ctx Context, organization, limit string) (*github.InteractionRestriction, *github.Response, error) func github.com/google/go-github/v66/github.(*InteractionsService).UpdateRestrictionsForRepo(ctx Context, owner, repo, limit string) (*github.InteractionRestriction, *github.Response, error) func github.com/google/go-github/v66/github.(*IssueImportService).CheckStatus(ctx Context, owner, repo string, issueID int64) (*github.IssueImportResponse, *github.Response, error) func github.com/google/go-github/v66/github.(*IssueImportService).CheckStatusSince(ctx Context, owner, repo string, since github.Timestamp) ([]*github.IssueImportResponse, *github.Response, error) func github.com/google/go-github/v66/github.(*IssueImportService).Create(ctx Context, owner, repo string, issue *github.IssueImportRequest) (*github.IssueImportResponse, *github.Response, error) func github.com/google/go-github/v66/github.(*IssuesService).AddAssignees(ctx Context, owner, repo string, number int, assignees []string) (*github.Issue, *github.Response, error) func github.com/google/go-github/v66/github.(*IssuesService).AddLabelsToIssue(ctx Context, owner string, repo string, number int, labels []string) ([]*github.Label, *github.Response, error) func github.com/google/go-github/v66/github.(*IssuesService).Create(ctx Context, owner string, repo string, issue *github.IssueRequest) (*github.Issue, *github.Response, error) func github.com/google/go-github/v66/github.(*IssuesService).CreateComment(ctx Context, owner string, repo string, number int, comment *github.IssueComment) (*github.IssueComment, *github.Response, error) func github.com/google/go-github/v66/github.(*IssuesService).CreateLabel(ctx Context, owner string, repo string, label *github.Label) (*github.Label, *github.Response, error) func github.com/google/go-github/v66/github.(*IssuesService).CreateMilestone(ctx Context, owner string, repo string, milestone *github.Milestone) (*github.Milestone, *github.Response, error) func github.com/google/go-github/v66/github.(*IssuesService).DeleteComment(ctx Context, owner string, repo string, commentID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*IssuesService).DeleteLabel(ctx Context, owner string, repo string, name string) (*github.Response, error) func github.com/google/go-github/v66/github.(*IssuesService).DeleteMilestone(ctx Context, owner string, repo string, number int) (*github.Response, error) func github.com/google/go-github/v66/github.(*IssuesService).Edit(ctx Context, owner string, repo string, number int, issue *github.IssueRequest) (*github.Issue, *github.Response, error) func github.com/google/go-github/v66/github.(*IssuesService).EditComment(ctx Context, owner string, repo string, commentID int64, comment *github.IssueComment) (*github.IssueComment, *github.Response, error) func github.com/google/go-github/v66/github.(*IssuesService).EditLabel(ctx Context, owner string, repo string, name string, label *github.Label) (*github.Label, *github.Response, error) func github.com/google/go-github/v66/github.(*IssuesService).EditMilestone(ctx Context, owner string, repo string, number int, milestone *github.Milestone) (*github.Milestone, *github.Response, error) func github.com/google/go-github/v66/github.(*IssuesService).Get(ctx Context, owner string, repo string, number int) (*github.Issue, *github.Response, error) func github.com/google/go-github/v66/github.(*IssuesService).GetComment(ctx Context, owner string, repo string, commentID int64) (*github.IssueComment, *github.Response, error) func github.com/google/go-github/v66/github.(*IssuesService).GetEvent(ctx Context, owner, repo string, id int64) (*github.IssueEvent, *github.Response, error) func github.com/google/go-github/v66/github.(*IssuesService).GetLabel(ctx Context, owner string, repo string, name string) (*github.Label, *github.Response, error) func github.com/google/go-github/v66/github.(*IssuesService).GetMilestone(ctx Context, owner string, repo string, number int) (*github.Milestone, *github.Response, error) func github.com/google/go-github/v66/github.(*IssuesService).IsAssignee(ctx Context, owner, repo, user string) (bool, *github.Response, error) func github.com/google/go-github/v66/github.(*IssuesService).List(ctx Context, all bool, opts *github.IssueListOptions) ([]*github.Issue, *github.Response, error) func github.com/google/go-github/v66/github.(*IssuesService).ListAssignees(ctx Context, owner, repo string, opts *github.ListOptions) ([]*github.User, *github.Response, error) func github.com/google/go-github/v66/github.(*IssuesService).ListByOrg(ctx Context, org string, opts *github.IssueListOptions) ([]*github.Issue, *github.Response, error) func github.com/google/go-github/v66/github.(*IssuesService).ListByRepo(ctx Context, owner string, repo string, opts *github.IssueListByRepoOptions) ([]*github.Issue, *github.Response, error) func github.com/google/go-github/v66/github.(*IssuesService).ListComments(ctx Context, owner string, repo string, number int, opts *github.IssueListCommentsOptions) ([]*github.IssueComment, *github.Response, error) func github.com/google/go-github/v66/github.(*IssuesService).ListIssueEvents(ctx Context, owner, repo string, number int, opts *github.ListOptions) ([]*github.IssueEvent, *github.Response, error) func github.com/google/go-github/v66/github.(*IssuesService).ListIssueTimeline(ctx Context, owner, repo string, number int, opts *github.ListOptions) ([]*github.Timeline, *github.Response, error) func github.com/google/go-github/v66/github.(*IssuesService).ListLabels(ctx Context, owner string, repo string, opts *github.ListOptions) ([]*github.Label, *github.Response, error) func github.com/google/go-github/v66/github.(*IssuesService).ListLabelsByIssue(ctx Context, owner string, repo string, number int, opts *github.ListOptions) ([]*github.Label, *github.Response, error) func github.com/google/go-github/v66/github.(*IssuesService).ListLabelsForMilestone(ctx Context, owner string, repo string, number int, opts *github.ListOptions) ([]*github.Label, *github.Response, error) func github.com/google/go-github/v66/github.(*IssuesService).ListMilestones(ctx Context, owner string, repo string, opts *github.MilestoneListOptions) ([]*github.Milestone, *github.Response, error) func github.com/google/go-github/v66/github.(*IssuesService).ListRepositoryEvents(ctx Context, owner, repo string, opts *github.ListOptions) ([]*github.IssueEvent, *github.Response, error) func github.com/google/go-github/v66/github.(*IssuesService).Lock(ctx Context, owner string, repo string, number int, opts *github.LockIssueOptions) (*github.Response, error) func github.com/google/go-github/v66/github.(*IssuesService).RemoveAssignees(ctx Context, owner, repo string, number int, assignees []string) (*github.Issue, *github.Response, error) func github.com/google/go-github/v66/github.(*IssuesService).RemoveLabelForIssue(ctx Context, owner string, repo string, number int, label string) (*github.Response, error) func github.com/google/go-github/v66/github.(*IssuesService).RemoveLabelsForIssue(ctx Context, owner string, repo string, number int) (*github.Response, error) func github.com/google/go-github/v66/github.(*IssuesService).RemoveMilestone(ctx Context, owner, repo string, issueNumber int) (*github.Issue, *github.Response, error) func github.com/google/go-github/v66/github.(*IssuesService).ReplaceLabelsForIssue(ctx Context, owner string, repo string, number int, labels []string) ([]*github.Label, *github.Response, error) func github.com/google/go-github/v66/github.(*IssuesService).Unlock(ctx Context, owner string, repo string, number int) (*github.Response, error) func github.com/google/go-github/v66/github.(*LicensesService).Get(ctx Context, licenseName string) (*github.License, *github.Response, error) func github.com/google/go-github/v66/github.(*LicensesService).List(ctx Context) ([]*github.License, *github.Response, error) func github.com/google/go-github/v66/github.(*MarkdownService).Render(ctx Context, text string, opts *github.MarkdownOptions) (string, *github.Response, error) func github.com/google/go-github/v66/github.(*MarketplaceService).GetPlanAccountForAccount(ctx Context, accountID int64) (*github.MarketplacePlanAccount, *github.Response, error) func github.com/google/go-github/v66/github.(*MarketplaceService).ListMarketplacePurchasesForUser(ctx Context, opts *github.ListOptions) ([]*github.MarketplacePurchase, *github.Response, error) func github.com/google/go-github/v66/github.(*MarketplaceService).ListPlanAccountsForPlan(ctx Context, planID int64, opts *github.ListOptions) ([]*github.MarketplacePlanAccount, *github.Response, error) func github.com/google/go-github/v66/github.(*MarketplaceService).ListPlans(ctx Context, opts *github.ListOptions) ([]*github.MarketplacePlan, *github.Response, error) func github.com/google/go-github/v66/github.(*MetaService).Get(ctx Context) (*github.APIMeta, *github.Response, error) func github.com/google/go-github/v66/github.(*MetaService).Octocat(ctx Context, message string) (string, *github.Response, error) func github.com/google/go-github/v66/github.(*MetaService).Zen(ctx Context) (string, *github.Response, error) func github.com/google/go-github/v66/github.(*MigrationService).CancelImport(ctx Context, owner, repo string) (*github.Response, error) func github.com/google/go-github/v66/github.(*MigrationService).CommitAuthors(ctx Context, owner, repo string) ([]*github.SourceImportAuthor, *github.Response, error) func github.com/google/go-github/v66/github.(*MigrationService).DeleteMigration(ctx Context, org string, id int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*MigrationService).DeleteUserMigration(ctx Context, id int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*MigrationService).ImportProgress(ctx Context, owner, repo string) (*github.Import, *github.Response, error) func github.com/google/go-github/v66/github.(*MigrationService).LargeFiles(ctx Context, owner, repo string) ([]*github.LargeFile, *github.Response, error) func github.com/google/go-github/v66/github.(*MigrationService).ListMigrations(ctx Context, org string, opts *github.ListOptions) ([]*github.Migration, *github.Response, error) func github.com/google/go-github/v66/github.(*MigrationService).ListUserMigrations(ctx Context, opts *github.ListOptions) ([]*github.UserMigration, *github.Response, error) func github.com/google/go-github/v66/github.(*MigrationService).MapCommitAuthor(ctx Context, owner, repo string, id int64, author *github.SourceImportAuthor) (*github.SourceImportAuthor, *github.Response, error) func github.com/google/go-github/v66/github.(*MigrationService).MigrationArchiveURL(ctx Context, org string, id int64) (url string, err error) func github.com/google/go-github/v66/github.(*MigrationService).MigrationStatus(ctx Context, org string, id int64) (*github.Migration, *github.Response, error) func github.com/google/go-github/v66/github.(*MigrationService).SetLFSPreference(ctx Context, owner, repo string, in *github.Import) (*github.Import, *github.Response, error) func github.com/google/go-github/v66/github.(*MigrationService).StartImport(ctx Context, owner, repo string, in *github.Import) (*github.Import, *github.Response, error) func github.com/google/go-github/v66/github.(*MigrationService).StartMigration(ctx Context, org string, repos []string, opts *github.MigrationOptions) (*github.Migration, *github.Response, error) func github.com/google/go-github/v66/github.(*MigrationService).StartUserMigration(ctx Context, repos []string, opts *github.UserMigrationOptions) (*github.UserMigration, *github.Response, error) func github.com/google/go-github/v66/github.(*MigrationService).UnlockRepo(ctx Context, org string, id int64, repo string) (*github.Response, error) func github.com/google/go-github/v66/github.(*MigrationService).UnlockUserRepo(ctx Context, id int64, repo string) (*github.Response, error) func github.com/google/go-github/v66/github.(*MigrationService).UpdateImport(ctx Context, owner, repo string, in *github.Import) (*github.Import, *github.Response, error) func github.com/google/go-github/v66/github.(*MigrationService).UserMigrationArchiveURL(ctx Context, id int64) (string, error) func github.com/google/go-github/v66/github.(*MigrationService).UserMigrationStatus(ctx Context, id int64) (*github.UserMigration, *github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).AddSecurityManagerTeam(ctx Context, org, team string) (*github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).AssignOrgRoleToTeam(ctx Context, org, teamSlug string, roleID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).AssignOrgRoleToUser(ctx Context, org, username string, roleID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).BlockUser(ctx Context, org string, user string) (*github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).CancelInvite(ctx Context, org string, invitationID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).ConcealMembership(ctx Context, org, user string) (*github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).ConvertMemberToOutsideCollaborator(ctx Context, org string, user string) (*github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).CreateCustomOrgRole(ctx Context, org string, opts *github.CreateOrUpdateOrgRoleOptions) (*github.CustomOrgRoles, *github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).CreateCustomRepoRole(ctx Context, org string, opts *github.CreateOrUpdateCustomRepoRoleOptions) (*github.CustomRepoRoles, *github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).CreateHook(ctx Context, org string, hook *github.Hook) (*github.Hook, *github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).CreateOrganizationRuleset(ctx Context, org string, rs *github.Ruleset) (*github.Ruleset, *github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).CreateOrgInvitation(ctx Context, org string, opts *github.CreateOrgInvitationOptions) (*github.Invitation, *github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).CreateOrUpdateCustomProperties(ctx Context, org string, properties []*github.CustomProperty) ([]*github.CustomProperty, *github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).CreateOrUpdateCustomProperty(ctx Context, org, customPropertyName string, property *github.CustomProperty) (*github.CustomProperty, *github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).CreateOrUpdateRepoCustomPropertyValues(ctx Context, org string, repoNames []string, properties []*github.CustomPropertyValue) (*github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).CreateProject(ctx Context, org string, opts *github.ProjectOptions) (*github.Project, *github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).Delete(ctx Context, org string) (*github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).DeleteCustomOrgRole(ctx Context, org string, roleID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).DeleteCustomRepoRole(ctx Context, org string, roleID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).DeleteHook(ctx Context, org string, id int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).DeleteOrganizationRuleset(ctx Context, org string, rulesetID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).DeletePackage(ctx Context, org, packageType, packageName string) (*github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).Edit(ctx Context, name string, org *github.Organization) (*github.Organization, *github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).EditActionsAllowed(ctx Context, org string, actionsAllowed github.ActionsAllowed) (*github.ActionsAllowed, *github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).EditActionsPermissions(ctx Context, org string, actionsPermissions github.ActionsPermissions) (*github.ActionsPermissions, *github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).EditHook(ctx Context, org string, id int64, hook *github.Hook) (*github.Hook, *github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).EditHookConfiguration(ctx Context, org string, id int64, config *github.HookConfig) (*github.HookConfig, *github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).EditOrgMembership(ctx Context, user, org string, membership *github.Membership) (*github.Membership, *github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).Get(ctx Context, org string) (*github.Organization, *github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).GetActionsAllowed(ctx Context, org string) (*github.ActionsAllowed, *github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).GetActionsPermissions(ctx Context, org string) (*github.ActionsPermissions, *github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).GetAllCustomProperties(ctx Context, org string) ([]*github.CustomProperty, *github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).GetAllOrganizationRulesets(ctx Context, org string) ([]*github.Ruleset, *github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).GetAuditLog(ctx Context, org string, opts *github.GetAuditLogOptions) ([]*github.AuditEntry, *github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).GetByID(ctx Context, id int64) (*github.Organization, *github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).GetCustomProperty(ctx Context, org, name string) (*github.CustomProperty, *github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).GetHook(ctx Context, org string, id int64) (*github.Hook, *github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).GetHookConfiguration(ctx Context, org string, id int64) (*github.HookConfig, *github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).GetHookDelivery(ctx Context, owner string, hookID, deliveryID int64) (*github.HookDelivery, *github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).GetOrganizationRuleset(ctx Context, org string, rulesetID int64) (*github.Ruleset, *github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).GetOrgMembership(ctx Context, user, org string) (*github.Membership, *github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).GetOrgRole(ctx Context, org string, roleID int64) (*github.CustomOrgRoles, *github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).GetPackage(ctx Context, org, packageType, packageName string) (*github.Package, *github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).IsBlocked(ctx Context, org string, user string) (bool, *github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).IsMember(ctx Context, org, user string) (bool, *github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).IsPublicMember(ctx Context, org, user string) (bool, *github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).List(ctx Context, user string, opts *github.ListOptions) ([]*github.Organization, *github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).ListAll(ctx Context, opts *github.OrganizationsListOptions) ([]*github.Organization, *github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).ListBlockedUsers(ctx Context, org string, opts *github.ListOptions) ([]*github.User, *github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).ListCredentialAuthorizations(ctx Context, org string, opts *github.CredentialAuthorizationsListOptions) ([]*github.CredentialAuthorization, *github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).ListCustomPropertyValues(ctx Context, org string, opts *github.ListOptions) ([]*github.RepoCustomPropertyValue, *github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).ListCustomRepoRoles(ctx Context, org string) (*github.OrganizationCustomRepoRoles, *github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).ListFailedOrgInvitations(ctx Context, org string, opts *github.ListOptions) ([]*github.Invitation, *github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).ListFineGrainedPersonalAccessTokens(ctx Context, org string, opts *github.ListFineGrainedPATOptions) ([]*github.PersonalAccessToken, *github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).ListHookDeliveries(ctx Context, org string, id int64, opts *github.ListCursorOptions) ([]*github.HookDelivery, *github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).ListHooks(ctx Context, org string, opts *github.ListOptions) ([]*github.Hook, *github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).ListInstallations(ctx Context, org string, opts *github.ListOptions) (*github.OrganizationInstallations, *github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).ListMembers(ctx Context, org string, opts *github.ListMembersOptions) ([]*github.User, *github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).ListOrgInvitationTeams(ctx Context, org, invitationID string, opts *github.ListOptions) ([]*github.Team, *github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).ListOrgMemberships(ctx Context, opts *github.ListOrgMembershipsOptions) ([]*github.Membership, *github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).ListOutsideCollaborators(ctx Context, org string, opts *github.ListOutsideCollaboratorsOptions) ([]*github.User, *github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).ListPackages(ctx Context, org string, opts *github.PackageListOptions) ([]*github.Package, *github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).ListPendingOrgInvitations(ctx Context, org string, opts *github.ListOptions) ([]*github.Invitation, *github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).ListProjects(ctx Context, org string, opts *github.ProjectListOptions) ([]*github.Project, *github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).ListRoles(ctx Context, org string) (*github.OrganizationCustomRoles, *github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).ListSecurityManagerTeams(ctx Context, org string) ([]*github.Team, *github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).ListTeamsAssignedToOrgRole(ctx Context, org string, roleID int64, opts *github.ListOptions) ([]*github.Team, *github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).ListUsersAssignedToOrgRole(ctx Context, org string, roleID int64, opts *github.ListOptions) ([]*github.User, *github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).PackageDeleteVersion(ctx Context, org, packageType, packageName string, packageVersionID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).PackageGetAllVersions(ctx Context, org, packageType, packageName string, opts *github.PackageListOptions) ([]*github.PackageVersion, *github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).PackageGetVersion(ctx Context, org, packageType, packageName string, packageVersionID int64) (*github.PackageVersion, *github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).PackageRestoreVersion(ctx Context, org, packageType, packageName string, packageVersionID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).PingHook(ctx Context, org string, id int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).PublicizeMembership(ctx Context, org, user string) (*github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).RedeliverHookDelivery(ctx Context, owner string, hookID, deliveryID int64) (*github.HookDelivery, *github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).RemoveCredentialAuthorization(ctx Context, org string, credentialID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).RemoveCustomProperty(ctx Context, org, customPropertyName string) (*github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).RemoveMember(ctx Context, org, user string) (*github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).RemoveOrgMembership(ctx Context, user, org string) (*github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).RemoveOrgRoleFromTeam(ctx Context, org, teamSlug string, roleID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).RemoveOrgRoleFromUser(ctx Context, org, username string, roleID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).RemoveOutsideCollaborator(ctx Context, org string, user string) (*github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).RemoveSecurityManagerTeam(ctx Context, org, team string) (*github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).RestorePackage(ctx Context, org, packageType, packageName string) (*github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).ReviewPersonalAccessTokenRequest(ctx Context, org string, requestID int64, opts github.ReviewPersonalAccessTokenRequestOptions) (*github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).UnblockUser(ctx Context, org string, user string) (*github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).UpdateCustomOrgRole(ctx Context, org string, roleID int64, opts *github.CreateOrUpdateOrgRoleOptions) (*github.CustomOrgRoles, *github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).UpdateCustomRepoRole(ctx Context, org string, roleID int64, opts *github.CreateOrUpdateCustomRepoRoleOptions) (*github.CustomRepoRoles, *github.Response, error) func github.com/google/go-github/v66/github.(*OrganizationsService).UpdateOrganizationRuleset(ctx Context, org string, rulesetID int64, rs *github.Ruleset) (*github.Ruleset, *github.Response, error) func github.com/google/go-github/v66/github.(*ProjectsService).AddProjectCollaborator(ctx Context, id int64, username string, opts *github.ProjectCollaboratorOptions) (*github.Response, error) func github.com/google/go-github/v66/github.(*ProjectsService).CreateProjectCard(ctx Context, columnID int64, opts *github.ProjectCardOptions) (*github.ProjectCard, *github.Response, error) func github.com/google/go-github/v66/github.(*ProjectsService).CreateProjectColumn(ctx Context, projectID int64, opts *github.ProjectColumnOptions) (*github.ProjectColumn, *github.Response, error) func github.com/google/go-github/v66/github.(*ProjectsService).DeleteProject(ctx Context, id int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*ProjectsService).DeleteProjectCard(ctx Context, cardID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*ProjectsService).DeleteProjectColumn(ctx Context, columnID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*ProjectsService).GetProject(ctx Context, id int64) (*github.Project, *github.Response, error) func github.com/google/go-github/v66/github.(*ProjectsService).GetProjectCard(ctx Context, cardID int64) (*github.ProjectCard, *github.Response, error) func github.com/google/go-github/v66/github.(*ProjectsService).GetProjectColumn(ctx Context, id int64) (*github.ProjectColumn, *github.Response, error) func github.com/google/go-github/v66/github.(*ProjectsService).ListProjectCards(ctx Context, columnID int64, opts *github.ProjectCardListOptions) ([]*github.ProjectCard, *github.Response, error) func github.com/google/go-github/v66/github.(*ProjectsService).ListProjectCollaborators(ctx Context, id int64, opts *github.ListCollaboratorOptions) ([]*github.User, *github.Response, error) func github.com/google/go-github/v66/github.(*ProjectsService).ListProjectColumns(ctx Context, projectID int64, opts *github.ListOptions) ([]*github.ProjectColumn, *github.Response, error) func github.com/google/go-github/v66/github.(*ProjectsService).MoveProjectCard(ctx Context, cardID int64, opts *github.ProjectCardMoveOptions) (*github.Response, error) func github.com/google/go-github/v66/github.(*ProjectsService).MoveProjectColumn(ctx Context, columnID int64, opts *github.ProjectColumnMoveOptions) (*github.Response, error) func github.com/google/go-github/v66/github.(*ProjectsService).RemoveProjectCollaborator(ctx Context, id int64, username string) (*github.Response, error) func github.com/google/go-github/v66/github.(*ProjectsService).ReviewProjectCollaboratorPermission(ctx Context, id int64, username string) (*github.ProjectPermissionLevel, *github.Response, error) func github.com/google/go-github/v66/github.(*ProjectsService).UpdateProject(ctx Context, id int64, opts *github.ProjectOptions) (*github.Project, *github.Response, error) func github.com/google/go-github/v66/github.(*ProjectsService).UpdateProjectCard(ctx Context, cardID int64, opts *github.ProjectCardOptions) (*github.ProjectCard, *github.Response, error) func github.com/google/go-github/v66/github.(*ProjectsService).UpdateProjectColumn(ctx Context, columnID int64, opts *github.ProjectColumnOptions) (*github.ProjectColumn, *github.Response, error) func github.com/google/go-github/v66/github.(*PullRequestsService).Create(ctx Context, owner string, repo string, pull *github.NewPullRequest) (*github.PullRequest, *github.Response, error) func github.com/google/go-github/v66/github.(*PullRequestsService).CreateComment(ctx Context, owner, repo string, number int, comment *github.PullRequestComment) (*github.PullRequestComment, *github.Response, error) func github.com/google/go-github/v66/github.(*PullRequestsService).CreateCommentInReplyTo(ctx Context, owner, repo string, number int, body string, commentID int64) (*github.PullRequestComment, *github.Response, error) func github.com/google/go-github/v66/github.(*PullRequestsService).CreateReview(ctx Context, owner, repo string, number int, review *github.PullRequestReviewRequest) (*github.PullRequestReview, *github.Response, error) func github.com/google/go-github/v66/github.(*PullRequestsService).DeleteComment(ctx Context, owner, repo string, commentID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*PullRequestsService).DeletePendingReview(ctx Context, owner, repo string, number int, reviewID int64) (*github.PullRequestReview, *github.Response, error) func github.com/google/go-github/v66/github.(*PullRequestsService).DismissReview(ctx Context, owner, repo string, number int, reviewID int64, review *github.PullRequestReviewDismissalRequest) (*github.PullRequestReview, *github.Response, error) func github.com/google/go-github/v66/github.(*PullRequestsService).Edit(ctx Context, owner string, repo string, number int, pull *github.PullRequest) (*github.PullRequest, *github.Response, error) func github.com/google/go-github/v66/github.(*PullRequestsService).EditComment(ctx Context, owner, repo string, commentID int64, comment *github.PullRequestComment) (*github.PullRequestComment, *github.Response, error) func github.com/google/go-github/v66/github.(*PullRequestsService).Get(ctx Context, owner string, repo string, number int) (*github.PullRequest, *github.Response, error) func github.com/google/go-github/v66/github.(*PullRequestsService).GetComment(ctx Context, owner, repo string, commentID int64) (*github.PullRequestComment, *github.Response, error) func github.com/google/go-github/v66/github.(*PullRequestsService).GetRaw(ctx Context, owner string, repo string, number int, opts github.RawOptions) (string, *github.Response, error) func github.com/google/go-github/v66/github.(*PullRequestsService).GetReview(ctx Context, owner, repo string, number int, reviewID int64) (*github.PullRequestReview, *github.Response, error) func github.com/google/go-github/v66/github.(*PullRequestsService).IsMerged(ctx Context, owner string, repo string, number int) (bool, *github.Response, error) func github.com/google/go-github/v66/github.(*PullRequestsService).List(ctx Context, owner string, repo string, opts *github.PullRequestListOptions) ([]*github.PullRequest, *github.Response, error) func github.com/google/go-github/v66/github.(*PullRequestsService).ListComments(ctx Context, owner, repo string, number int, opts *github.PullRequestListCommentsOptions) ([]*github.PullRequestComment, *github.Response, error) func github.com/google/go-github/v66/github.(*PullRequestsService).ListCommits(ctx Context, owner string, repo string, number int, opts *github.ListOptions) ([]*github.RepositoryCommit, *github.Response, error) func github.com/google/go-github/v66/github.(*PullRequestsService).ListFiles(ctx Context, owner string, repo string, number int, opts *github.ListOptions) ([]*github.CommitFile, *github.Response, error) func github.com/google/go-github/v66/github.(*PullRequestsService).ListPullRequestsWithCommit(ctx Context, owner, repo, sha string, opts *github.ListOptions) ([]*github.PullRequest, *github.Response, error) func github.com/google/go-github/v66/github.(*PullRequestsService).ListReviewComments(ctx Context, owner, repo string, number int, reviewID int64, opts *github.ListOptions) ([]*github.PullRequestComment, *github.Response, error) func github.com/google/go-github/v66/github.(*PullRequestsService).ListReviewers(ctx Context, owner, repo string, number int, opts *github.ListOptions) (*github.Reviewers, *github.Response, error) func github.com/google/go-github/v66/github.(*PullRequestsService).ListReviews(ctx Context, owner, repo string, number int, opts *github.ListOptions) ([]*github.PullRequestReview, *github.Response, error) func github.com/google/go-github/v66/github.(*PullRequestsService).Merge(ctx Context, owner string, repo string, number int, commitMessage string, options *github.PullRequestOptions) (*github.PullRequestMergeResult, *github.Response, error) func github.com/google/go-github/v66/github.(*PullRequestsService).RemoveReviewers(ctx Context, owner, repo string, number int, reviewers github.ReviewersRequest) (*github.Response, error) func github.com/google/go-github/v66/github.(*PullRequestsService).RequestReviewers(ctx Context, owner, repo string, number int, reviewers github.ReviewersRequest) (*github.PullRequest, *github.Response, error) func github.com/google/go-github/v66/github.(*PullRequestsService).SubmitReview(ctx Context, owner, repo string, number int, reviewID int64, review *github.PullRequestReviewRequest) (*github.PullRequestReview, *github.Response, error) func github.com/google/go-github/v66/github.(*PullRequestsService).UpdateBranch(ctx Context, owner, repo string, number int, opts *github.PullRequestBranchUpdateOptions) (*github.PullRequestBranchUpdateResponse, *github.Response, error) func github.com/google/go-github/v66/github.(*PullRequestsService).UpdateReview(ctx Context, owner, repo string, number int, reviewID int64, body string) (*github.PullRequestReview, *github.Response, error) func github.com/google/go-github/v66/github.(*RateLimitService).Get(ctx Context) (*github.RateLimits, *github.Response, error) func github.com/google/go-github/v66/github.(*ReactionsService).CreateCommentReaction(ctx Context, owner, repo string, id int64, content string) (*github.Reaction, *github.Response, error) func github.com/google/go-github/v66/github.(*ReactionsService).CreateIssueCommentReaction(ctx Context, owner, repo string, id int64, content string) (*github.Reaction, *github.Response, error) func github.com/google/go-github/v66/github.(*ReactionsService).CreateIssueReaction(ctx Context, owner, repo string, number int, content string) (*github.Reaction, *github.Response, error) func github.com/google/go-github/v66/github.(*ReactionsService).CreatePullRequestCommentReaction(ctx Context, owner, repo string, id int64, content string) (*github.Reaction, *github.Response, error) func github.com/google/go-github/v66/github.(*ReactionsService).CreateReleaseReaction(ctx Context, owner, repo string, releaseID int64, content string) (*github.Reaction, *github.Response, error) func github.com/google/go-github/v66/github.(*ReactionsService).CreateTeamDiscussionCommentReaction(ctx Context, teamID int64, discussionNumber, commentNumber int, content string) (*github.Reaction, *github.Response, error) func github.com/google/go-github/v66/github.(*ReactionsService).CreateTeamDiscussionReaction(ctx Context, teamID int64, discussionNumber int, content string) (*github.Reaction, *github.Response, error) func github.com/google/go-github/v66/github.(*ReactionsService).DeleteCommentReaction(ctx Context, owner, repo string, commentID, reactionID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*ReactionsService).DeleteCommentReactionByID(ctx Context, repoID, commentID, reactionID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*ReactionsService).DeleteIssueCommentReaction(ctx Context, owner, repo string, commentID, reactionID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*ReactionsService).DeleteIssueCommentReactionByID(ctx Context, repoID, commentID, reactionID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*ReactionsService).DeleteIssueReaction(ctx Context, owner, repo string, issueNumber int, reactionID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*ReactionsService).DeleteIssueReactionByID(ctx Context, repoID, issueNumber int, reactionID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*ReactionsService).DeletePullRequestCommentReaction(ctx Context, owner, repo string, commentID, reactionID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*ReactionsService).DeletePullRequestCommentReactionByID(ctx Context, repoID, commentID, reactionID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*ReactionsService).DeleteTeamDiscussionCommentReaction(ctx Context, org, teamSlug string, discussionNumber, commentNumber int, reactionID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*ReactionsService).DeleteTeamDiscussionCommentReactionByOrgIDAndTeamID(ctx Context, orgID, teamID, discussionNumber, commentNumber int, reactionID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*ReactionsService).DeleteTeamDiscussionReaction(ctx Context, org, teamSlug string, discussionNumber int, reactionID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*ReactionsService).DeleteTeamDiscussionReactionByOrgIDAndTeamID(ctx Context, orgID, teamID, discussionNumber int, reactionID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*ReactionsService).ListCommentReactions(ctx Context, owner, repo string, id int64, opts *github.ListCommentReactionOptions) ([]*github.Reaction, *github.Response, error) func github.com/google/go-github/v66/github.(*ReactionsService).ListIssueCommentReactions(ctx Context, owner, repo string, id int64, opts *github.ListOptions) ([]*github.Reaction, *github.Response, error) func github.com/google/go-github/v66/github.(*ReactionsService).ListIssueReactions(ctx Context, owner, repo string, number int, opts *github.ListOptions) ([]*github.Reaction, *github.Response, error) func github.com/google/go-github/v66/github.(*ReactionsService).ListPullRequestCommentReactions(ctx Context, owner, repo string, id int64, opts *github.ListOptions) ([]*github.Reaction, *github.Response, error) func github.com/google/go-github/v66/github.(*ReactionsService).ListTeamDiscussionCommentReactions(ctx Context, teamID int64, discussionNumber, commentNumber int, opts *github.ListOptions) ([]*github.Reaction, *github.Response, error) func github.com/google/go-github/v66/github.(*ReactionsService).ListTeamDiscussionReactions(ctx Context, teamID int64, discussionNumber int, opts *github.ListOptions) ([]*github.Reaction, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).AddAdminEnforcement(ctx Context, owner, repo, branch string) (*github.AdminEnforcement, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).AddAppRestrictions(ctx Context, owner, repo, branch string, apps []string) ([]*github.App, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).AddAutolink(ctx Context, owner, repo string, opts *github.AutolinkOptions) (*github.Autolink, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).AddCollaborator(ctx Context, owner, repo, user string, opts *github.RepositoryAddCollaboratorOptions) (*github.CollaboratorInvitation, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).AddTeamRestrictions(ctx Context, owner, repo, branch string, teams []string) ([]*github.Team, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).AddUserRestrictions(ctx Context, owner, repo, branch string, users []string) ([]*github.User, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).CompareCommits(ctx Context, owner, repo string, base, head string, opts *github.ListOptions) (*github.CommitsComparison, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).CompareCommitsRaw(ctx Context, owner, repo, base, head string, opts github.RawOptions) (string, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).Create(ctx Context, org string, repo *github.Repository) (*github.Repository, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).CreateComment(ctx Context, owner, repo, sha string, comment *github.RepositoryComment) (*github.RepositoryComment, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).CreateCustomDeploymentProtectionRule(ctx Context, owner, repo, environment string, request *github.CustomDeploymentProtectionRuleRequest) (*github.CustomDeploymentProtectionRule, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).CreateDeployment(ctx Context, owner, repo string, request *github.DeploymentRequest) (*github.Deployment, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).CreateDeploymentBranchPolicy(ctx Context, owner, repo, environment string, request *github.DeploymentBranchPolicyRequest) (*github.DeploymentBranchPolicy, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).CreateDeploymentStatus(ctx Context, owner, repo string, deployment int64, request *github.DeploymentStatusRequest) (*github.DeploymentStatus, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).CreateFile(ctx Context, owner, repo, path string, opts *github.RepositoryContentFileOptions) (*github.RepositoryContentResponse, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).CreateFork(ctx Context, owner, repo string, opts *github.RepositoryCreateForkOptions) (*github.Repository, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).CreateFromTemplate(ctx Context, templateOwner, templateRepo string, templateRepoReq *github.TemplateRepoRequest) (*github.Repository, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).CreateHook(ctx Context, owner, repo string, hook *github.Hook) (*github.Hook, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).CreateKey(ctx Context, owner string, repo string, key *github.Key) (*github.Key, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).CreateOrUpdateCustomProperties(ctx Context, org, repo string, customPropertyValues []*github.CustomPropertyValue) (*github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).CreateProject(ctx Context, owner, repo string, opts *github.ProjectOptions) (*github.Project, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).CreateRelease(ctx Context, owner, repo string, release *github.RepositoryRelease) (*github.RepositoryRelease, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).CreateRuleset(ctx Context, owner, repo string, rs *github.Ruleset) (*github.Ruleset, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).CreateStatus(ctx Context, owner, repo, ref string, status *github.RepoStatus) (*github.RepoStatus, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).CreateTagProtection(ctx Context, owner, repo, pattern string) (*github.TagProtection, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).CreateUpdateEnvironment(ctx Context, owner, repo, name string, environment *github.CreateUpdateEnvironment) (*github.Environment, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).Delete(ctx Context, owner, repo string) (*github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).DeleteAutolink(ctx Context, owner, repo string, id int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).DeleteComment(ctx Context, owner, repo string, id int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).DeleteDeployment(ctx Context, owner, repo string, deploymentID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).DeleteDeploymentBranchPolicy(ctx Context, owner, repo, environment string, branchPolicyID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).DeleteEnvironment(ctx Context, owner, repo, name string) (*github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).DeleteFile(ctx Context, owner, repo, path string, opts *github.RepositoryContentFileOptions) (*github.RepositoryContentResponse, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).DeleteHook(ctx Context, owner, repo string, id int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).DeleteInvitation(ctx Context, owner, repo string, invitationID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).DeleteKey(ctx Context, owner string, repo string, id int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).DeletePreReceiveHook(ctx Context, owner, repo string, id int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).DeleteRelease(ctx Context, owner, repo string, id int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).DeleteReleaseAsset(ctx Context, owner, repo string, id int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).DeleteRuleset(ctx Context, owner, repo string, rulesetID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).DeleteTagProtection(ctx Context, owner, repo string, tagProtectionID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).DisableAutomatedSecurityFixes(ctx Context, owner, repository string) (*github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).DisableCustomDeploymentProtectionRule(ctx Context, owner, repo, environment string, protectionRuleID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).DisableDismissalRestrictions(ctx Context, owner, repo, branch string) (*github.PullRequestReviewsEnforcement, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).DisableLFS(ctx Context, owner, repo string) (*github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).DisablePages(ctx Context, owner, repo string) (*github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).DisablePrivateReporting(ctx Context, owner, repo string) (*github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).DisableVulnerabilityAlerts(ctx Context, owner, repository string) (*github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).Dispatch(ctx Context, owner, repo string, opts github.DispatchRequestOptions) (*github.Repository, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).DownloadContents(ctx Context, owner, repo, filepath string, opts *github.RepositoryContentGetOptions) (io.ReadCloser, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).DownloadContentsWithMeta(ctx Context, owner, repo, filepath string, opts *github.RepositoryContentGetOptions) (io.ReadCloser, *github.RepositoryContent, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).DownloadReleaseAsset(ctx Context, owner, repo string, id int64, followRedirectsClient *http.Client) (rc io.ReadCloser, redirectURL string, err error) func github.com/google/go-github/v66/github.(*RepositoriesService).Edit(ctx Context, owner, repo string, repository *github.Repository) (*github.Repository, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).EditActionsAccessLevel(ctx Context, owner, repo string, repositoryActionsAccessLevel github.RepositoryActionsAccessLevel) (*github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).EditActionsAllowed(ctx Context, org, repo string, actionsAllowed github.ActionsAllowed) (*github.ActionsAllowed, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).EditActionsPermissions(ctx Context, owner, repo string, actionsPermissionsRepository github.ActionsPermissionsRepository) (*github.ActionsPermissionsRepository, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).EditDefaultWorkflowPermissions(ctx Context, owner, repo string, permissions github.DefaultWorkflowPermissionRepository) (*github.DefaultWorkflowPermissionRepository, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).EditHook(ctx Context, owner, repo string, id int64, hook *github.Hook) (*github.Hook, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).EditHookConfiguration(ctx Context, owner, repo string, id int64, config *github.HookConfig) (*github.HookConfig, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).EditRelease(ctx Context, owner, repo string, id int64, release *github.RepositoryRelease) (*github.RepositoryRelease, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).EditReleaseAsset(ctx Context, owner, repo string, id int64, release *github.ReleaseAsset) (*github.ReleaseAsset, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).EnableAutomatedSecurityFixes(ctx Context, owner, repository string) (*github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).EnableLFS(ctx Context, owner, repo string) (*github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).EnablePages(ctx Context, owner, repo string, pages *github.Pages) (*github.Pages, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).EnablePrivateReporting(ctx Context, owner, repo string) (*github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).EnableVulnerabilityAlerts(ctx Context, owner, repository string) (*github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).GenerateReleaseNotes(ctx Context, owner, repo string, opts *github.GenerateNotesOptions) (*github.RepositoryReleaseNotes, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).Get(ctx Context, owner, repo string) (*github.Repository, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).GetActionsAccessLevel(ctx Context, owner, repo string) (*github.RepositoryActionsAccessLevel, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).GetActionsAllowed(ctx Context, org, repo string) (*github.ActionsAllowed, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).GetActionsPermissions(ctx Context, owner, repo string) (*github.ActionsPermissionsRepository, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).GetAdminEnforcement(ctx Context, owner, repo, branch string) (*github.AdminEnforcement, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).GetAllCustomPropertyValues(ctx Context, org, repo string) ([]*github.CustomPropertyValue, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).GetAllDeploymentProtectionRules(ctx Context, owner, repo, environment string) (*github.ListDeploymentProtectionRuleResponse, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).GetAllRulesets(ctx Context, owner, repo string, includesParents bool) ([]*github.Ruleset, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).GetArchiveLink(ctx Context, owner, repo string, archiveformat github.ArchiveFormat, opts *github.RepositoryContentGetOptions, maxRedirects int) (*url.URL, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).GetAutolink(ctx Context, owner, repo string, id int64) (*github.Autolink, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).GetAutomatedSecurityFixes(ctx Context, owner, repository string) (*github.AutomatedSecurityFixes, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).GetBranch(ctx Context, owner, repo, branch string, maxRedirects int) (*github.Branch, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).GetBranchProtection(ctx Context, owner, repo, branch string) (*github.Protection, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).GetByID(ctx Context, id int64) (*github.Repository, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).GetCodeOfConduct(ctx Context, owner, repo string) (*github.CodeOfConduct, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).GetCodeownersErrors(ctx Context, owner, repo string, opts *github.GetCodeownersErrorsOptions) (*github.CodeownersErrors, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).GetCombinedStatus(ctx Context, owner, repo, ref string, opts *github.ListOptions) (*github.CombinedStatus, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).GetComment(ctx Context, owner, repo string, id int64) (*github.RepositoryComment, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).GetCommit(ctx Context, owner, repo, sha string, opts *github.ListOptions) (*github.RepositoryCommit, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).GetCommitRaw(ctx Context, owner string, repo string, sha string, opts github.RawOptions) (string, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).GetCommitSHA1(ctx Context, owner, repo, ref, lastSHA string) (string, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).GetCommunityHealthMetrics(ctx Context, owner, repo string) (*github.CommunityHealthMetrics, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).GetContents(ctx Context, owner, repo, path string, opts *github.RepositoryContentGetOptions) (fileContent *github.RepositoryContent, directoryContent []*github.RepositoryContent, resp *github.Response, err error) func github.com/google/go-github/v66/github.(*RepositoriesService).GetCustomDeploymentProtectionRule(ctx Context, owner, repo, environment string, protectionRuleID int64) (*github.CustomDeploymentProtectionRule, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).GetDefaultWorkflowPermissions(ctx Context, owner, repo string) (*github.DefaultWorkflowPermissionRepository, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).GetDeployment(ctx Context, owner, repo string, deploymentID int64) (*github.Deployment, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).GetDeploymentBranchPolicy(ctx Context, owner, repo, environment string, branchPolicyID int64) (*github.DeploymentBranchPolicy, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).GetDeploymentStatus(ctx Context, owner, repo string, deploymentID, deploymentStatusID int64) (*github.DeploymentStatus, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).GetEnvironment(ctx Context, owner, repo, name string) (*github.Environment, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).GetHook(ctx Context, owner, repo string, id int64) (*github.Hook, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).GetHookConfiguration(ctx Context, owner, repo string, id int64) (*github.HookConfig, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).GetHookDelivery(ctx Context, owner, repo string, hookID, deliveryID int64) (*github.HookDelivery, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).GetKey(ctx Context, owner string, repo string, id int64) (*github.Key, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).GetLatestPagesBuild(ctx Context, owner, repo string) (*github.PagesBuild, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).GetLatestRelease(ctx Context, owner, repo string) (*github.RepositoryRelease, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).GetPageBuild(ctx Context, owner, repo string, id int64) (*github.PagesBuild, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).GetPageHealthCheck(ctx Context, owner, repo string) (*github.PagesHealthCheckResponse, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).GetPagesInfo(ctx Context, owner, repo string) (*github.Pages, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).GetPermissionLevel(ctx Context, owner, repo, user string) (*github.RepositoryPermissionLevel, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).GetPreReceiveHook(ctx Context, owner, repo string, id int64) (*github.PreReceiveHook, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).GetPullRequestReviewEnforcement(ctx Context, owner, repo, branch string) (*github.PullRequestReviewsEnforcement, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).GetReadme(ctx Context, owner, repo string, opts *github.RepositoryContentGetOptions) (*github.RepositoryContent, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).GetRelease(ctx Context, owner, repo string, id int64) (*github.RepositoryRelease, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).GetReleaseAsset(ctx Context, owner, repo string, id int64) (*github.ReleaseAsset, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).GetReleaseByTag(ctx Context, owner, repo, tag string) (*github.RepositoryRelease, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).GetRequiredStatusChecks(ctx Context, owner, repo, branch string) (*github.RequiredStatusChecks, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).GetRuleset(ctx Context, owner, repo string, rulesetID int64, includesParents bool) (*github.Ruleset, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).GetRulesForBranch(ctx Context, owner, repo, branch string) ([]*github.RepositoryRule, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).GetSignaturesProtectedBranch(ctx Context, owner, repo, branch string) (*github.SignaturesProtectedBranch, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).GetVulnerabilityAlerts(ctx Context, owner, repository string) (bool, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).IsCollaborator(ctx Context, owner, repo, user string) (bool, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).IsPrivateReportingEnabled(ctx Context, owner, repo string) (bool, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).License(ctx Context, owner, repo string) (*github.RepositoryLicense, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).List(ctx Context, user string, opts *github.RepositoryListOptions) ([]*github.Repository, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).ListAll(ctx Context, opts *github.RepositoryListAllOptions) ([]*github.Repository, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).ListAllTopics(ctx Context, owner, repo string) ([]string, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).ListAppRestrictions(ctx Context, owner, repo, branch string) ([]*github.App, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).ListApps(ctx Context, owner, repo, branch string) ([]*github.App, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).ListAutolinks(ctx Context, owner, repo string, opts *github.ListOptions) ([]*github.Autolink, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).ListBranches(ctx Context, owner string, repo string, opts *github.BranchListOptions) ([]*github.Branch, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).ListBranchesHeadCommit(ctx Context, owner, repo, sha string) ([]*github.BranchCommit, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).ListByAuthenticatedUser(ctx Context, opts *github.RepositoryListByAuthenticatedUserOptions) ([]*github.Repository, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).ListByOrg(ctx Context, org string, opts *github.RepositoryListByOrgOptions) ([]*github.Repository, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).ListByUser(ctx Context, user string, opts *github.RepositoryListByUserOptions) ([]*github.Repository, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).ListCodeFrequency(ctx Context, owner, repo string) ([]*github.WeeklyStats, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).ListCollaborators(ctx Context, owner, repo string, opts *github.ListCollaboratorsOptions) ([]*github.User, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).ListComments(ctx Context, owner, repo string, opts *github.ListOptions) ([]*github.RepositoryComment, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).ListCommitActivity(ctx Context, owner, repo string) ([]*github.WeeklyCommitActivity, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).ListCommitComments(ctx Context, owner, repo, sha string, opts *github.ListOptions) ([]*github.RepositoryComment, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).ListCommits(ctx Context, owner, repo string, opts *github.CommitsListOptions) ([]*github.RepositoryCommit, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).ListContributors(ctx Context, owner string, repository string, opts *github.ListContributorsOptions) ([]*github.Contributor, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).ListContributorsStats(ctx Context, owner, repo string) ([]*github.ContributorStats, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).ListCustomDeploymentRuleIntegrations(ctx Context, owner, repo, environment string) (*github.ListCustomDeploymentRuleIntegrationsResponse, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).ListDeploymentBranchPolicies(ctx Context, owner, repo, environment string) (*github.DeploymentBranchPolicyResponse, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).ListDeployments(ctx Context, owner, repo string, opts *github.DeploymentsListOptions) ([]*github.Deployment, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).ListDeploymentStatuses(ctx Context, owner, repo string, deployment int64, opts *github.ListOptions) ([]*github.DeploymentStatus, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).ListEnvironments(ctx Context, owner, repo string, opts *github.EnvironmentListOptions) (*github.EnvResponse, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).ListForks(ctx Context, owner, repo string, opts *github.RepositoryListForksOptions) ([]*github.Repository, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).ListHookDeliveries(ctx Context, owner, repo string, id int64, opts *github.ListCursorOptions) ([]*github.HookDelivery, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).ListHooks(ctx Context, owner, repo string, opts *github.ListOptions) ([]*github.Hook, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).ListInvitations(ctx Context, owner, repo string, opts *github.ListOptions) ([]*github.RepositoryInvitation, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).ListKeys(ctx Context, owner string, repo string, opts *github.ListOptions) ([]*github.Key, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).ListLanguages(ctx Context, owner string, repo string) (map[string]int, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).ListPagesBuilds(ctx Context, owner, repo string, opts *github.ListOptions) ([]*github.PagesBuild, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).ListParticipation(ctx Context, owner, repo string) (*github.RepositoryParticipation, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).ListPreReceiveHooks(ctx Context, owner, repo string, opts *github.ListOptions) ([]*github.PreReceiveHook, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).ListProjects(ctx Context, owner, repo string, opts *github.ProjectListOptions) ([]*github.Project, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).ListPunchCard(ctx Context, owner, repo string) ([]*github.PunchCard, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).ListReleaseAssets(ctx Context, owner, repo string, id int64, opts *github.ListOptions) ([]*github.ReleaseAsset, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).ListReleases(ctx Context, owner, repo string, opts *github.ListOptions) ([]*github.RepositoryRelease, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).ListRequiredStatusChecksContexts(ctx Context, owner, repo, branch string) (contexts []string, resp *github.Response, err error) func github.com/google/go-github/v66/github.(*RepositoriesService).ListStatuses(ctx Context, owner, repo, ref string, opts *github.ListOptions) ([]*github.RepoStatus, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).ListTagProtection(ctx Context, owner, repo string) ([]*github.TagProtection, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).ListTags(ctx Context, owner string, repo string, opts *github.ListOptions) ([]*github.RepositoryTag, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).ListTeamRestrictions(ctx Context, owner, repo, branch string) ([]*github.Team, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).ListTeams(ctx Context, owner string, repo string, opts *github.ListOptions) ([]*github.Team, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).ListTrafficClones(ctx Context, owner, repo string, opts *github.TrafficBreakdownOptions) (*github.TrafficClones, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).ListTrafficPaths(ctx Context, owner, repo string) ([]*github.TrafficPath, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).ListTrafficReferrers(ctx Context, owner, repo string) ([]*github.TrafficReferrer, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).ListTrafficViews(ctx Context, owner, repo string, opts *github.TrafficBreakdownOptions) (*github.TrafficViews, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).ListUserRestrictions(ctx Context, owner, repo, branch string) ([]*github.User, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).Merge(ctx Context, owner, repo string, request *github.RepositoryMergeRequest) (*github.RepositoryCommit, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).MergeUpstream(ctx Context, owner, repo string, request *github.RepoMergeUpstreamRequest) (*github.RepoMergeUpstreamResult, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).OptionalSignaturesOnProtectedBranch(ctx Context, owner, repo, branch string) (*github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).PingHook(ctx Context, owner, repo string, id int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).RedeliverHookDelivery(ctx Context, owner, repo string, hookID, deliveryID int64) (*github.HookDelivery, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).RemoveAdminEnforcement(ctx Context, owner, repo, branch string) (*github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).RemoveAppRestrictions(ctx Context, owner, repo, branch string, apps []string) ([]*github.App, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).RemoveBranchProtection(ctx Context, owner, repo, branch string) (*github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).RemoveCollaborator(ctx Context, owner, repo, user string) (*github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).RemovePullRequestReviewEnforcement(ctx Context, owner, repo, branch string) (*github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).RemoveRequiredStatusChecks(ctx Context, owner, repo, branch string) (*github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).RemoveTeamRestrictions(ctx Context, owner, repo, branch string, teams []string) ([]*github.Team, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).RemoveUserRestrictions(ctx Context, owner, repo, branch string, users []string) ([]*github.User, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).RenameBranch(ctx Context, owner, repo, branch, newName string) (*github.Branch, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).ReplaceAllTopics(ctx Context, owner, repo string, topics []string) ([]string, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).ReplaceAppRestrictions(ctx Context, owner, repo, branch string, apps []string) ([]*github.App, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).ReplaceTeamRestrictions(ctx Context, owner, repo, branch string, teams []string) ([]*github.Team, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).ReplaceUserRestrictions(ctx Context, owner, repo, branch string, users []string) ([]*github.User, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).RequestPageBuild(ctx Context, owner, repo string) (*github.PagesBuild, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).RequireSignaturesOnProtectedBranch(ctx Context, owner, repo, branch string) (*github.SignaturesProtectedBranch, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).Subscribe(ctx Context, owner, repo, event, callback string, secret []byte) (*github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).TestHook(ctx Context, owner, repo string, id int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).Transfer(ctx Context, owner, repo string, transfer github.TransferRequest) (*github.Repository, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).Unsubscribe(ctx Context, owner, repo, event, callback string, secret []byte) (*github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).UpdateBranchProtection(ctx Context, owner, repo, branch string, preq *github.ProtectionRequest) (*github.Protection, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).UpdateComment(ctx Context, owner, repo string, id int64, comment *github.RepositoryComment) (*github.RepositoryComment, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).UpdateDeploymentBranchPolicy(ctx Context, owner, repo, environment string, branchPolicyID int64, request *github.DeploymentBranchPolicyRequest) (*github.DeploymentBranchPolicy, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).UpdateFile(ctx Context, owner, repo, path string, opts *github.RepositoryContentFileOptions) (*github.RepositoryContentResponse, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).UpdateInvitation(ctx Context, owner, repo string, invitationID int64, permissions string) (*github.RepositoryInvitation, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).UpdatePages(ctx Context, owner, repo string, opts *github.PagesUpdate) (*github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).UpdatePreReceiveHook(ctx Context, owner, repo string, id int64, hook *github.PreReceiveHook) (*github.PreReceiveHook, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).UpdatePullRequestReviewEnforcement(ctx Context, owner, repo, branch string, patch *github.PullRequestReviewsEnforcementUpdate) (*github.PullRequestReviewsEnforcement, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).UpdateRequiredStatusChecks(ctx Context, owner, repo, branch string, sreq *github.RequiredStatusChecksRequest) (*github.RequiredStatusChecks, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).UpdateRuleset(ctx Context, owner, repo string, rulesetID int64, rs *github.Ruleset) (*github.Ruleset, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).UpdateRulesetNoBypassActor(ctx Context, owner, repo string, rulesetID int64, rs *github.Ruleset) (*github.Ruleset, *github.Response, error) func github.com/google/go-github/v66/github.(*RepositoriesService).UploadReleaseAsset(ctx Context, owner, repo string, id int64, opts *github.UploadOptions, file *os.File) (*github.ReleaseAsset, *github.Response, error) func github.com/google/go-github/v66/github.(*SCIMService).DeleteSCIMUserFromOrg(ctx Context, org, scimUserID string) (*github.Response, error) func github.com/google/go-github/v66/github.(*SCIMService).GetSCIMProvisioningInfoForUser(ctx Context, org, scimUserID string) (*github.SCIMUserAttributes, *github.Response, error) func github.com/google/go-github/v66/github.(*SCIMService).ListSCIMProvisionedIdentities(ctx Context, org string, opts *github.ListSCIMProvisionedIdentitiesOptions) (*github.SCIMProvisionedIdentities, *github.Response, error) func github.com/google/go-github/v66/github.(*SCIMService).ProvisionAndInviteSCIMUser(ctx Context, org string, opts *github.SCIMUserAttributes) (*github.SCIMUserAttributes, *github.Response, error) func github.com/google/go-github/v66/github.(*SCIMService).UpdateAttributeForSCIMUser(ctx Context, org, scimUserID string, opts *github.UpdateAttributeForSCIMUserOptions) (*github.Response, error) func github.com/google/go-github/v66/github.(*SCIMService).UpdateProvisionedOrgMembership(ctx Context, org, scimUserID string, opts *github.SCIMUserAttributes) (*github.Response, error) func github.com/google/go-github/v66/github.(*SearchService).Code(ctx Context, query string, opts *github.SearchOptions) (*github.CodeSearchResult, *github.Response, error) func github.com/google/go-github/v66/github.(*SearchService).Commits(ctx Context, query string, opts *github.SearchOptions) (*github.CommitsSearchResult, *github.Response, error) func github.com/google/go-github/v66/github.(*SearchService).Issues(ctx Context, query string, opts *github.SearchOptions) (*github.IssuesSearchResult, *github.Response, error) func github.com/google/go-github/v66/github.(*SearchService).Labels(ctx Context, repoID int64, query string, opts *github.SearchOptions) (*github.LabelsSearchResult, *github.Response, error) func github.com/google/go-github/v66/github.(*SearchService).Repositories(ctx Context, query string, opts *github.SearchOptions) (*github.RepositoriesSearchResult, *github.Response, error) func github.com/google/go-github/v66/github.(*SearchService).Topics(ctx Context, query string, opts *github.SearchOptions) (*github.TopicsSearchResult, *github.Response, error) func github.com/google/go-github/v66/github.(*SearchService).Users(ctx Context, query string, opts *github.SearchOptions) (*github.UsersSearchResult, *github.Response, error) func github.com/google/go-github/v66/github.(*SecretScanningService).GetAlert(ctx Context, owner, repo string, number int64) (*github.SecretScanningAlert, *github.Response, error) func github.com/google/go-github/v66/github.(*SecretScanningService).ListAlertsForEnterprise(ctx Context, enterprise string, opts *github.SecretScanningAlertListOptions) ([]*github.SecretScanningAlert, *github.Response, error) func github.com/google/go-github/v66/github.(*SecretScanningService).ListAlertsForOrg(ctx Context, org string, opts *github.SecretScanningAlertListOptions) ([]*github.SecretScanningAlert, *github.Response, error) func github.com/google/go-github/v66/github.(*SecretScanningService).ListAlertsForRepo(ctx Context, owner, repo string, opts *github.SecretScanningAlertListOptions) ([]*github.SecretScanningAlert, *github.Response, error) func github.com/google/go-github/v66/github.(*SecretScanningService).ListLocationsForAlert(ctx Context, owner, repo string, number int64, opts *github.ListOptions) ([]*github.SecretScanningAlertLocation, *github.Response, error) func github.com/google/go-github/v66/github.(*SecretScanningService).UpdateAlert(ctx Context, owner, repo string, number int64, opts *github.SecretScanningAlertUpdateOptions) (*github.SecretScanningAlert, *github.Response, error) func github.com/google/go-github/v66/github.(*SecurityAdvisoriesService).CreateTemporaryPrivateFork(ctx Context, owner, repo, ghsaID string) (*github.Repository, *github.Response, error) func github.com/google/go-github/v66/github.(*SecurityAdvisoriesService).GetGlobalSecurityAdvisories(ctx Context, ghsaID string) (*github.GlobalSecurityAdvisory, *github.Response, error) func github.com/google/go-github/v66/github.(*SecurityAdvisoriesService).ListGlobalSecurityAdvisories(ctx Context, opts *github.ListGlobalSecurityAdvisoriesOptions) ([]*github.GlobalSecurityAdvisory, *github.Response, error) func github.com/google/go-github/v66/github.(*SecurityAdvisoriesService).ListRepositorySecurityAdvisories(ctx Context, owner, repo string, opt *github.ListRepositorySecurityAdvisoriesOptions) ([]*github.SecurityAdvisory, *github.Response, error) func github.com/google/go-github/v66/github.(*SecurityAdvisoriesService).ListRepositorySecurityAdvisoriesForOrg(ctx Context, org string, opt *github.ListRepositorySecurityAdvisoriesOptions) ([]*github.SecurityAdvisory, *github.Response, error) func github.com/google/go-github/v66/github.(*SecurityAdvisoriesService).RequestCVE(ctx Context, owner, repo, ghsaID string) (*github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).AddTeamMembershipByID(ctx Context, orgID, teamID int64, user string, opts *github.TeamAddTeamMembershipOptions) (*github.Membership, *github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).AddTeamMembershipBySlug(ctx Context, org, slug, user string, opts *github.TeamAddTeamMembershipOptions) (*github.Membership, *github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).AddTeamProjectByID(ctx Context, orgID, teamID, projectID int64, opts *github.TeamProjectOptions) (*github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).AddTeamProjectBySlug(ctx Context, org, slug string, projectID int64, opts *github.TeamProjectOptions) (*github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).AddTeamRepoByID(ctx Context, orgID, teamID int64, owner, repo string, opts *github.TeamAddTeamRepoOptions) (*github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).AddTeamRepoBySlug(ctx Context, org, slug, owner, repo string, opts *github.TeamAddTeamRepoOptions) (*github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).CreateCommentByID(ctx Context, orgID, teamID int64, discussionNumber int, comment github.DiscussionComment) (*github.DiscussionComment, *github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).CreateCommentBySlug(ctx Context, org, slug string, discsusionNumber int, comment github.DiscussionComment) (*github.DiscussionComment, *github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).CreateDiscussionByID(ctx Context, orgID, teamID int64, discussion github.TeamDiscussion) (*github.TeamDiscussion, *github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).CreateDiscussionBySlug(ctx Context, org, slug string, discussion github.TeamDiscussion) (*github.TeamDiscussion, *github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).CreateOrUpdateIDPGroupConnectionsByID(ctx Context, orgID, teamID int64, opts github.IDPGroupList) (*github.IDPGroupList, *github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).CreateOrUpdateIDPGroupConnectionsBySlug(ctx Context, org, slug string, opts github.IDPGroupList) (*github.IDPGroupList, *github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).CreateTeam(ctx Context, org string, team github.NewTeam) (*github.Team, *github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).DeleteCommentByID(ctx Context, orgID, teamID int64, discussionNumber, commentNumber int) (*github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).DeleteCommentBySlug(ctx Context, org, slug string, discussionNumber, commentNumber int) (*github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).DeleteDiscussionByID(ctx Context, orgID, teamID int64, discussionNumber int) (*github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).DeleteDiscussionBySlug(ctx Context, org, slug string, discussionNumber int) (*github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).DeleteTeamByID(ctx Context, orgID, teamID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).DeleteTeamBySlug(ctx Context, org, slug string) (*github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).EditCommentByID(ctx Context, orgID, teamID int64, discussionNumber, commentNumber int, comment github.DiscussionComment) (*github.DiscussionComment, *github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).EditCommentBySlug(ctx Context, org, slug string, discussionNumber, commentNumber int, comment github.DiscussionComment) (*github.DiscussionComment, *github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).EditDiscussionByID(ctx Context, orgID, teamID int64, discussionNumber int, discussion github.TeamDiscussion) (*github.TeamDiscussion, *github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).EditDiscussionBySlug(ctx Context, org, slug string, discussionNumber int, discussion github.TeamDiscussion) (*github.TeamDiscussion, *github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).EditTeamByID(ctx Context, orgID, teamID int64, team github.NewTeam, removeParent bool) (*github.Team, *github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).EditTeamBySlug(ctx Context, org, slug string, team github.NewTeam, removeParent bool) (*github.Team, *github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).GetCommentByID(ctx Context, orgID, teamID int64, discussionNumber, commentNumber int) (*github.DiscussionComment, *github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).GetCommentBySlug(ctx Context, org, slug string, discussionNumber, commentNumber int) (*github.DiscussionComment, *github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).GetDiscussionByID(ctx Context, orgID, teamID int64, discussionNumber int) (*github.TeamDiscussion, *github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).GetDiscussionBySlug(ctx Context, org, slug string, discussionNumber int) (*github.TeamDiscussion, *github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).GetExternalGroup(ctx Context, org string, groupID int64) (*github.ExternalGroup, *github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).GetTeamByID(ctx Context, orgID, teamID int64) (*github.Team, *github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).GetTeamBySlug(ctx Context, org, slug string) (*github.Team, *github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).GetTeamMembershipByID(ctx Context, orgID, teamID int64, user string) (*github.Membership, *github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).GetTeamMembershipBySlug(ctx Context, org, slug, user string) (*github.Membership, *github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).IsTeamRepoByID(ctx Context, orgID, teamID int64, owner, repo string) (*github.Repository, *github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).IsTeamRepoBySlug(ctx Context, org, slug, owner, repo string) (*github.Repository, *github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).ListChildTeamsByParentID(ctx Context, orgID, teamID int64, opts *github.ListOptions) ([]*github.Team, *github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).ListChildTeamsByParentSlug(ctx Context, org, slug string, opts *github.ListOptions) ([]*github.Team, *github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).ListCommentsByID(ctx Context, orgID, teamID int64, discussionNumber int, options *github.DiscussionCommentListOptions) ([]*github.DiscussionComment, *github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).ListCommentsBySlug(ctx Context, org, slug string, discussionNumber int, options *github.DiscussionCommentListOptions) ([]*github.DiscussionComment, *github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).ListDiscussionsByID(ctx Context, orgID, teamID int64, opts *github.DiscussionListOptions) ([]*github.TeamDiscussion, *github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).ListDiscussionsBySlug(ctx Context, org, slug string, opts *github.DiscussionListOptions) ([]*github.TeamDiscussion, *github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).ListExternalGroups(ctx Context, org string, opts *github.ListExternalGroupsOptions) (*github.ExternalGroupList, *github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).ListExternalGroupsForTeamBySlug(ctx Context, org, slug string) (*github.ExternalGroupList, *github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).ListIDPGroupsForTeamByID(ctx Context, orgID, teamID int64) (*github.IDPGroupList, *github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).ListIDPGroupsForTeamBySlug(ctx Context, org, slug string) (*github.IDPGroupList, *github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).ListIDPGroupsInOrganization(ctx Context, org string, opts *github.ListIDPGroupsOptions) (*github.IDPGroupList, *github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).ListPendingTeamInvitationsByID(ctx Context, orgID, teamID int64, opts *github.ListOptions) ([]*github.Invitation, *github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).ListPendingTeamInvitationsBySlug(ctx Context, org, slug string, opts *github.ListOptions) ([]*github.Invitation, *github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).ListTeamMembersByID(ctx Context, orgID, teamID int64, opts *github.TeamListTeamMembersOptions) ([]*github.User, *github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).ListTeamMembersBySlug(ctx Context, org, slug string, opts *github.TeamListTeamMembersOptions) ([]*github.User, *github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).ListTeamProjectsByID(ctx Context, orgID, teamID int64) ([]*github.Project, *github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).ListTeamProjectsBySlug(ctx Context, org, slug string) ([]*github.Project, *github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).ListTeamReposByID(ctx Context, orgID, teamID int64, opts *github.ListOptions) ([]*github.Repository, *github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).ListTeamReposBySlug(ctx Context, org, slug string, opts *github.ListOptions) ([]*github.Repository, *github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).ListTeams(ctx Context, org string, opts *github.ListOptions) ([]*github.Team, *github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).ListUserTeams(ctx Context, opts *github.ListOptions) ([]*github.Team, *github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).RemoveConnectedExternalGroup(ctx Context, org, slug string) (*github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).RemoveTeamMembershipByID(ctx Context, orgID, teamID int64, user string) (*github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).RemoveTeamMembershipBySlug(ctx Context, org, slug, user string) (*github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).RemoveTeamProjectByID(ctx Context, orgID, teamID, projectID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).RemoveTeamProjectBySlug(ctx Context, org, slug string, projectID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).RemoveTeamRepoByID(ctx Context, orgID, teamID int64, owner, repo string) (*github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).RemoveTeamRepoBySlug(ctx Context, org, slug, owner, repo string) (*github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).ReviewTeamProjectsByID(ctx Context, orgID, teamID, projectID int64) (*github.Project, *github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).ReviewTeamProjectsBySlug(ctx Context, org, slug string, projectID int64) (*github.Project, *github.Response, error) func github.com/google/go-github/v66/github.(*TeamsService).UpdateConnectedExternalGroup(ctx Context, org, slug string, eg *github.ExternalGroup) (*github.ExternalGroup, *github.Response, error) func github.com/google/go-github/v66/github.(*UsersService).AcceptInvitation(ctx Context, invitationID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*UsersService).AddEmails(ctx Context, emails []string) ([]*github.UserEmail, *github.Response, error) func github.com/google/go-github/v66/github.(*UsersService).BlockUser(ctx Context, user string) (*github.Response, error) func github.com/google/go-github/v66/github.(*UsersService).CreateGPGKey(ctx Context, armoredPublicKey string) (*github.GPGKey, *github.Response, error) func github.com/google/go-github/v66/github.(*UsersService).CreateKey(ctx Context, key *github.Key) (*github.Key, *github.Response, error) func github.com/google/go-github/v66/github.(*UsersService).CreateProject(ctx Context, opts *github.CreateUserProjectOptions) (*github.Project, *github.Response, error) func github.com/google/go-github/v66/github.(*UsersService).CreateSSHSigningKey(ctx Context, key *github.Key) (*github.SSHSigningKey, *github.Response, error) func github.com/google/go-github/v66/github.(*UsersService).DeclineInvitation(ctx Context, invitationID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*UsersService).DeleteEmails(ctx Context, emails []string) (*github.Response, error) func github.com/google/go-github/v66/github.(*UsersService).DeleteGPGKey(ctx Context, id int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*UsersService).DeleteKey(ctx Context, id int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*UsersService).DeletePackage(ctx Context, user, packageType, packageName string) (*github.Response, error) func github.com/google/go-github/v66/github.(*UsersService).DeleteSSHSigningKey(ctx Context, id int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*UsersService).DemoteSiteAdmin(ctx Context, user string) (*github.Response, error) func github.com/google/go-github/v66/github.(*UsersService).Edit(ctx Context, user *github.User) (*github.User, *github.Response, error) func github.com/google/go-github/v66/github.(*UsersService).Follow(ctx Context, user string) (*github.Response, error) func github.com/google/go-github/v66/github.(*UsersService).Get(ctx Context, user string) (*github.User, *github.Response, error) func github.com/google/go-github/v66/github.(*UsersService).GetByID(ctx Context, id int64) (*github.User, *github.Response, error) func github.com/google/go-github/v66/github.(*UsersService).GetGPGKey(ctx Context, id int64) (*github.GPGKey, *github.Response, error) func github.com/google/go-github/v66/github.(*UsersService).GetHovercard(ctx Context, user string, opts *github.HovercardOptions) (*github.Hovercard, *github.Response, error) func github.com/google/go-github/v66/github.(*UsersService).GetKey(ctx Context, id int64) (*github.Key, *github.Response, error) func github.com/google/go-github/v66/github.(*UsersService).GetPackage(ctx Context, user, packageType, packageName string) (*github.Package, *github.Response, error) func github.com/google/go-github/v66/github.(*UsersService).GetSSHSigningKey(ctx Context, id int64) (*github.SSHSigningKey, *github.Response, error) func github.com/google/go-github/v66/github.(*UsersService).IsBlocked(ctx Context, user string) (bool, *github.Response, error) func github.com/google/go-github/v66/github.(*UsersService).IsFollowing(ctx Context, user, target string) (bool, *github.Response, error) func github.com/google/go-github/v66/github.(*UsersService).ListAll(ctx Context, opts *github.UserListOptions) ([]*github.User, *github.Response, error) func github.com/google/go-github/v66/github.(*UsersService).ListBlockedUsers(ctx Context, opts *github.ListOptions) ([]*github.User, *github.Response, error) func github.com/google/go-github/v66/github.(*UsersService).ListEmails(ctx Context, opts *github.ListOptions) ([]*github.UserEmail, *github.Response, error) func github.com/google/go-github/v66/github.(*UsersService).ListFollowers(ctx Context, user string, opts *github.ListOptions) ([]*github.User, *github.Response, error) func github.com/google/go-github/v66/github.(*UsersService).ListFollowing(ctx Context, user string, opts *github.ListOptions) ([]*github.User, *github.Response, error) func github.com/google/go-github/v66/github.(*UsersService).ListGPGKeys(ctx Context, user string, opts *github.ListOptions) ([]*github.GPGKey, *github.Response, error) func github.com/google/go-github/v66/github.(*UsersService).ListInvitations(ctx Context, opts *github.ListOptions) ([]*github.RepositoryInvitation, *github.Response, error) func github.com/google/go-github/v66/github.(*UsersService).ListKeys(ctx Context, user string, opts *github.ListOptions) ([]*github.Key, *github.Response, error) func github.com/google/go-github/v66/github.(*UsersService).ListPackages(ctx Context, user string, opts *github.PackageListOptions) ([]*github.Package, *github.Response, error) func github.com/google/go-github/v66/github.(*UsersService).ListProjects(ctx Context, user string, opts *github.ProjectListOptions) ([]*github.Project, *github.Response, error) func github.com/google/go-github/v66/github.(*UsersService).ListSSHSigningKeys(ctx Context, user string, opts *github.ListOptions) ([]*github.SSHSigningKey, *github.Response, error) func github.com/google/go-github/v66/github.(*UsersService).PackageDeleteVersion(ctx Context, user, packageType, packageName string, packageVersionID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*UsersService).PackageGetAllVersions(ctx Context, user, packageType, packageName string, opts *github.PackageListOptions) ([]*github.PackageVersion, *github.Response, error) func github.com/google/go-github/v66/github.(*UsersService).PackageGetVersion(ctx Context, user, packageType, packageName string, packageVersionID int64) (*github.PackageVersion, *github.Response, error) func github.com/google/go-github/v66/github.(*UsersService).PackageRestoreVersion(ctx Context, user, packageType, packageName string, packageVersionID int64) (*github.Response, error) func github.com/google/go-github/v66/github.(*UsersService).PromoteSiteAdmin(ctx Context, user string) (*github.Response, error) func github.com/google/go-github/v66/github.(*UsersService).RestorePackage(ctx Context, user, packageType, packageName string) (*github.Response, error) func github.com/google/go-github/v66/github.(*UsersService).SetEmailVisibility(ctx Context, visibility string) ([]*github.UserEmail, *github.Response, error) func github.com/google/go-github/v66/github.(*UsersService).Suspend(ctx Context, user string, opts *github.UserSuspendOptions) (*github.Response, error) func github.com/google/go-github/v66/github.(*UsersService).UnblockUser(ctx Context, user string) (*github.Response, error) func github.com/google/go-github/v66/github.(*UsersService).Unfollow(ctx Context, user string) (*github.Response, error) func github.com/google/go-github/v66/github.(*UsersService).Unsuspend(ctx Context, user string) (*github.Response, error) func github.com/gorilla/websocket.(*Dialer).DialContext(ctx Context, urlStr string, requestHeader http.Header) (*websocket.Conn, *http.Response, error) func github.com/grpc-ecosystem/grpc-gateway/v2/runtime.AnnotateContext(ctx Context, mux *runtime.ServeMux, req *http.Request, rpcMethodName string, options ...runtime.AnnotateContextOption) (Context, error) func github.com/grpc-ecosystem/grpc-gateway/v2/runtime.AnnotateIncomingContext(ctx Context, mux *runtime.ServeMux, req *http.Request, rpcMethodName string, options ...runtime.AnnotateContextOption) (Context, error) func github.com/grpc-ecosystem/grpc-gateway/v2/runtime.DefaultHTTPErrorHandler(ctx Context, mux *runtime.ServeMux, marshaler runtime.Marshaler, w http.ResponseWriter, r *http.Request, err error) func github.com/grpc-ecosystem/grpc-gateway/v2/runtime.DefaultRoutingErrorHandler(ctx Context, mux *runtime.ServeMux, marshaler runtime.Marshaler, w http.ResponseWriter, r *http.Request, httpStatus int) func github.com/grpc-ecosystem/grpc-gateway/v2/runtime.DefaultStreamErrorHandler(_ Context, err error) *status.Status func github.com/grpc-ecosystem/grpc-gateway/v2/runtime.ForwardResponseMessage(ctx Context, mux *runtime.ServeMux, marshaler runtime.Marshaler, w http.ResponseWriter, req *http.Request, resp proto.Message, opts ...func(Context, http.ResponseWriter, proto.Message) error) func github.com/grpc-ecosystem/grpc-gateway/v2/runtime.ForwardResponseStream(ctx Context, mux *runtime.ServeMux, marshaler runtime.Marshaler, w http.ResponseWriter, req *http.Request, recv func() (proto.Message, error), opts ...func(Context, http.ResponseWriter, proto.Message) error) func github.com/grpc-ecosystem/grpc-gateway/v2/runtime.HTTPError(ctx Context, mux *runtime.ServeMux, marshaler runtime.Marshaler, w http.ResponseWriter, r *http.Request, err error) func github.com/grpc-ecosystem/grpc-gateway/v2/runtime.HTTPPathPattern(ctx Context) (string, bool) func github.com/grpc-ecosystem/grpc-gateway/v2/runtime.HTTPPattern(ctx Context) (runtime.Pattern, bool) func github.com/grpc-ecosystem/grpc-gateway/v2/runtime.HTTPStreamError(ctx Context, mux *runtime.ServeMux, marshaler runtime.Marshaler, w http.ResponseWriter, r *http.Request, err error) func github.com/grpc-ecosystem/grpc-gateway/v2/runtime.NewServerMetadataContext(ctx Context, md runtime.ServerMetadata) Context func github.com/grpc-ecosystem/grpc-gateway/v2/runtime.RPCMethod(ctx Context) (string, bool) func github.com/grpc-ecosystem/grpc-gateway/v2/runtime.ServerMetadataFromContext(ctx Context) (md runtime.ServerMetadata, ok bool) func github.com/hibiken/asynq.GetMaxRetry(ctx Context) (n int, ok bool) func github.com/hibiken/asynq.GetQueueName(ctx Context) (queue string, ok bool) func github.com/hibiken/asynq.GetRetryCount(ctx Context) (n int, ok bool) func github.com/hibiken/asynq.GetTaskID(ctx Context) (id string, ok bool) func github.com/hibiken/asynq.NotFound(ctx Context, task *asynq.Task) error func github.com/hibiken/asynq.(*Client).EnqueueContext(ctx Context, task *asynq.Task, opts ...asynq.Option) (*asynq.TaskInfo, error) func github.com/hibiken/asynq.ErrorHandler.HandleError(ctx Context, task *asynq.Task, err error) func github.com/hibiken/asynq.ErrorHandlerFunc.HandleError(ctx Context, task *asynq.Task, err error) func github.com/hibiken/asynq.Handler.ProcessTask(Context, *asynq.Task) error func github.com/hibiken/asynq.HandlerFunc.ProcessTask(ctx Context, task *asynq.Task) error func github.com/hibiken/asynq.(*ServeMux).ProcessTask(ctx Context, task *asynq.Task) error func github.com/hibiken/asynq/internal/base.Broker.AddToGroup(ctx Context, msg *base.TaskMessage, gname string) error func github.com/hibiken/asynq/internal/base.Broker.AddToGroupUnique(ctx Context, msg *base.TaskMessage, groupKey string, ttl time.Duration) error func github.com/hibiken/asynq/internal/base.Broker.Archive(ctx Context, msg *base.TaskMessage, errMsg string) error func github.com/hibiken/asynq/internal/base.Broker.DeleteAggregationSet(ctx Context, qname, gname, aggregationSetID string) error func github.com/hibiken/asynq/internal/base.Broker.Done(ctx Context, msg *base.TaskMessage) error func github.com/hibiken/asynq/internal/base.Broker.Enqueue(ctx Context, msg *base.TaskMessage) error func github.com/hibiken/asynq/internal/base.Broker.EnqueueUnique(ctx Context, msg *base.TaskMessage, ttl time.Duration) error func github.com/hibiken/asynq/internal/base.Broker.MarkAsComplete(ctx Context, msg *base.TaskMessage) error func github.com/hibiken/asynq/internal/base.Broker.Requeue(ctx Context, msg *base.TaskMessage) error func github.com/hibiken/asynq/internal/base.Broker.Retry(ctx Context, msg *base.TaskMessage, processAt time.Time, errMsg string, isFailure bool) error func github.com/hibiken/asynq/internal/base.Broker.Schedule(ctx Context, msg *base.TaskMessage, processAt time.Time) error func github.com/hibiken/asynq/internal/base.Broker.ScheduleUnique(ctx Context, msg *base.TaskMessage, processAt time.Time, ttl time.Duration) error func github.com/hibiken/asynq/internal/context.GetMaxRetry(ctx Context) (n int, ok bool) func github.com/hibiken/asynq/internal/context.GetQueueName(ctx Context) (qname string, ok bool) func github.com/hibiken/asynq/internal/context.GetRetryCount(ctx Context) (n int, ok bool) func github.com/hibiken/asynq/internal/context.GetTaskID(ctx Context) (id string, ok bool) func github.com/hibiken/asynq/internal/context.New(base Context, msg *base.TaskMessage, deadline time.Time) (Context, CancelFunc) func github.com/hibiken/asynq/internal/rdb.(*RDB).AddToGroup(ctx Context, msg *base.TaskMessage, groupKey string) error func github.com/hibiken/asynq/internal/rdb.(*RDB).AddToGroupUnique(ctx Context, msg *base.TaskMessage, groupKey string, ttl time.Duration) error func github.com/hibiken/asynq/internal/rdb.(*RDB).Archive(ctx Context, msg *base.TaskMessage, errMsg string) error func github.com/hibiken/asynq/internal/rdb.(*RDB).DeleteAggregationSet(ctx Context, qname, gname, setID string) error func github.com/hibiken/asynq/internal/rdb.(*RDB).Done(ctx Context, msg *base.TaskMessage) error func github.com/hibiken/asynq/internal/rdb.(*RDB).Enqueue(ctx Context, msg *base.TaskMessage) error func github.com/hibiken/asynq/internal/rdb.(*RDB).EnqueueUnique(ctx Context, msg *base.TaskMessage, ttl time.Duration) error func github.com/hibiken/asynq/internal/rdb.(*RDB).MarkAsComplete(ctx Context, msg *base.TaskMessage) error func github.com/hibiken/asynq/internal/rdb.(*RDB).Requeue(ctx Context, msg *base.TaskMessage) error func github.com/hibiken/asynq/internal/rdb.(*RDB).Retry(ctx Context, msg *base.TaskMessage, processAt time.Time, errMsg string, isFailure bool) error func github.com/hibiken/asynq/internal/rdb.(*RDB).Schedule(ctx Context, msg *base.TaskMessage, processAt time.Time) error func github.com/hibiken/asynq/internal/rdb.(*RDB).ScheduleUnique(ctx Context, msg *base.TaskMessage, processAt time.Time, ttl time.Duration) error func github.com/huin/goupnp.DeviceByURLCtx(ctx Context, loc *url.URL) (*goupnp.RootDevice, error) func github.com/huin/goupnp.DiscoverDevicesCtx(ctx Context, searchTarget string) ([]goupnp.MaybeRootDevice, error) func github.com/huin/goupnp.NewServiceClientsByURLCtx(ctx Context, loc *url.URL, searchTarget string) ([]goupnp.ServiceClient, error) func github.com/huin/goupnp.NewServiceClientsCtx(ctx Context, searchTarget string) (clients []goupnp.ServiceClient, errors []error, err error) func github.com/huin/goupnp.(*Service).RequestSCPDCtx(ctx Context) (*scpd.SCPD, error) func github.com/huin/goupnp/dcps/internetgateway1.NewLANHostConfigManagement1ClientsByURLCtx(ctx Context, loc *url.URL) ([]*internetgateway1.LANHostConfigManagement1, error) func github.com/huin/goupnp/dcps/internetgateway1.NewLANHostConfigManagement1ClientsCtx(ctx Context) (clients []*internetgateway1.LANHostConfigManagement1, errors []error, err error) func github.com/huin/goupnp/dcps/internetgateway1.NewLayer3Forwarding1ClientsByURLCtx(ctx Context, loc *url.URL) ([]*internetgateway1.Layer3Forwarding1, error) func github.com/huin/goupnp/dcps/internetgateway1.NewLayer3Forwarding1ClientsCtx(ctx Context) (clients []*internetgateway1.Layer3Forwarding1, errors []error, err error) func github.com/huin/goupnp/dcps/internetgateway1.NewWANCableLinkConfig1ClientsByURLCtx(ctx Context, loc *url.URL) ([]*internetgateway1.WANCableLinkConfig1, error) func github.com/huin/goupnp/dcps/internetgateway1.NewWANCableLinkConfig1ClientsCtx(ctx Context) (clients []*internetgateway1.WANCableLinkConfig1, errors []error, err error) func github.com/huin/goupnp/dcps/internetgateway1.NewWANCommonInterfaceConfig1ClientsByURLCtx(ctx Context, loc *url.URL) ([]*internetgateway1.WANCommonInterfaceConfig1, error) func github.com/huin/goupnp/dcps/internetgateway1.NewWANCommonInterfaceConfig1ClientsCtx(ctx Context) (clients []*internetgateway1.WANCommonInterfaceConfig1, errors []error, err error) func github.com/huin/goupnp/dcps/internetgateway1.NewWANDSLLinkConfig1ClientsByURLCtx(ctx Context, loc *url.URL) ([]*internetgateway1.WANDSLLinkConfig1, error) func github.com/huin/goupnp/dcps/internetgateway1.NewWANDSLLinkConfig1ClientsCtx(ctx Context) (clients []*internetgateway1.WANDSLLinkConfig1, errors []error, err error) func github.com/huin/goupnp/dcps/internetgateway1.NewWANEthernetLinkConfig1ClientsByURLCtx(ctx Context, loc *url.URL) ([]*internetgateway1.WANEthernetLinkConfig1, error) func github.com/huin/goupnp/dcps/internetgateway1.NewWANEthernetLinkConfig1ClientsCtx(ctx Context) (clients []*internetgateway1.WANEthernetLinkConfig1, errors []error, err error) func github.com/huin/goupnp/dcps/internetgateway1.NewWANIPConnection1ClientsByURLCtx(ctx Context, loc *url.URL) ([]*internetgateway1.WANIPConnection1, error) func github.com/huin/goupnp/dcps/internetgateway1.NewWANIPConnection1ClientsCtx(ctx Context) (clients []*internetgateway1.WANIPConnection1, errors []error, err error) func github.com/huin/goupnp/dcps/internetgateway1.NewWANPOTSLinkConfig1ClientsByURLCtx(ctx Context, loc *url.URL) ([]*internetgateway1.WANPOTSLinkConfig1, error) func github.com/huin/goupnp/dcps/internetgateway1.NewWANPOTSLinkConfig1ClientsCtx(ctx Context) (clients []*internetgateway1.WANPOTSLinkConfig1, errors []error, err error) func github.com/huin/goupnp/dcps/internetgateway1.NewWANPPPConnection1ClientsByURLCtx(ctx Context, loc *url.URL) ([]*internetgateway1.WANPPPConnection1, error) func github.com/huin/goupnp/dcps/internetgateway1.NewWANPPPConnection1ClientsCtx(ctx Context) (clients []*internetgateway1.WANPPPConnection1, errors []error, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*LANHostConfigManagement1).DeleteDNSServerCtx(ctx Context, NewDNSServers string) (err error) func github.com/huin/goupnp/dcps/internetgateway1.(*LANHostConfigManagement1).DeleteIPRouterCtx(ctx Context, NewIPRouters string) (err error) func github.com/huin/goupnp/dcps/internetgateway1.(*LANHostConfigManagement1).DeleteReservedAddressCtx(ctx Context, NewReservedAddresses string) (err error) func github.com/huin/goupnp/dcps/internetgateway1.(*LANHostConfigManagement1).GetAddressRangeCtx(ctx Context) (NewMinAddress string, NewMaxAddress string, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*LANHostConfigManagement1).GetDHCPRelayCtx(ctx Context) (NewDHCPRelay bool, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*LANHostConfigManagement1).GetDHCPServerConfigurableCtx(ctx Context) (NewDHCPServerConfigurable bool, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*LANHostConfigManagement1).GetDNSServersCtx(ctx Context) (NewDNSServers string, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*LANHostConfigManagement1).GetDomainNameCtx(ctx Context) (NewDomainName string, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*LANHostConfigManagement1).GetIPRoutersListCtx(ctx Context) (NewIPRouters string, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*LANHostConfigManagement1).GetReservedAddressesCtx(ctx Context) (NewReservedAddresses string, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*LANHostConfigManagement1).GetSubnetMaskCtx(ctx Context) (NewSubnetMask string, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*LANHostConfigManagement1).SetAddressRangeCtx(ctx Context, NewMinAddress string, NewMaxAddress string) (err error) func github.com/huin/goupnp/dcps/internetgateway1.(*LANHostConfigManagement1).SetDHCPRelayCtx(ctx Context, NewDHCPRelay bool) (err error) func github.com/huin/goupnp/dcps/internetgateway1.(*LANHostConfigManagement1).SetDHCPServerConfigurableCtx(ctx Context, NewDHCPServerConfigurable bool) (err error) func github.com/huin/goupnp/dcps/internetgateway1.(*LANHostConfigManagement1).SetDNSServerCtx(ctx Context, NewDNSServers string) (err error) func github.com/huin/goupnp/dcps/internetgateway1.(*LANHostConfigManagement1).SetDomainNameCtx(ctx Context, NewDomainName string) (err error) func github.com/huin/goupnp/dcps/internetgateway1.(*LANHostConfigManagement1).SetIPRouterCtx(ctx Context, NewIPRouters string) (err error) func github.com/huin/goupnp/dcps/internetgateway1.(*LANHostConfigManagement1).SetReservedAddressCtx(ctx Context, NewReservedAddresses string) (err error) func github.com/huin/goupnp/dcps/internetgateway1.(*LANHostConfigManagement1).SetSubnetMaskCtx(ctx Context, NewSubnetMask string) (err error) func github.com/huin/goupnp/dcps/internetgateway1.(*Layer3Forwarding1).GetDefaultConnectionServiceCtx(ctx Context) (NewDefaultConnectionService string, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*Layer3Forwarding1).SetDefaultConnectionServiceCtx(ctx Context, NewDefaultConnectionService string) (err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANCableLinkConfig1).GetBPIEncryptionEnabledCtx(ctx Context) (NewBPIEncryptionEnabled bool, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANCableLinkConfig1).GetCableLinkConfigInfoCtx(ctx Context) (NewCableLinkConfigState string, NewLinkType string, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANCableLinkConfig1).GetConfigFileCtx(ctx Context) (NewConfigFile string, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANCableLinkConfig1).GetDownstreamFrequencyCtx(ctx Context) (NewDownstreamFrequency uint32, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANCableLinkConfig1).GetDownstreamModulationCtx(ctx Context) (NewDownstreamModulation string, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANCableLinkConfig1).GetTFTPServerCtx(ctx Context) (NewTFTPServer string, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANCableLinkConfig1).GetUpstreamChannelIDCtx(ctx Context) (NewUpstreamChannelID uint32, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANCableLinkConfig1).GetUpstreamFrequencyCtx(ctx Context) (NewUpstreamFrequency uint32, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANCableLinkConfig1).GetUpstreamModulationCtx(ctx Context) (NewUpstreamModulation string, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANCableLinkConfig1).GetUpstreamPowerLevelCtx(ctx Context) (NewUpstreamPowerLevel uint32, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANCommonInterfaceConfig1).GetActiveConnectionCtx(ctx Context, NewActiveConnectionIndex uint16) (NewActiveConnDeviceContainer string, NewActiveConnectionServiceID string, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANCommonInterfaceConfig1).GetCommonLinkPropertiesCtx(ctx Context) (NewWANAccessType string, NewLayer1UpstreamMaxBitRate uint32, NewLayer1DownstreamMaxBitRate uint32, NewPhysicalLinkStatus string, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANCommonInterfaceConfig1).GetEnabledForInternetCtx(ctx Context) (NewEnabledForInternet bool, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANCommonInterfaceConfig1).GetMaximumActiveConnectionsCtx(ctx Context) (NewMaximumActiveConnections uint16, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANCommonInterfaceConfig1).GetTotalBytesReceivedCtx(ctx Context) (NewTotalBytesReceived uint64, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANCommonInterfaceConfig1).GetTotalBytesSentCtx(ctx Context) (NewTotalBytesSent uint64, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANCommonInterfaceConfig1).GetTotalPacketsReceivedCtx(ctx Context) (NewTotalPacketsReceived uint32, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANCommonInterfaceConfig1).GetTotalPacketsSentCtx(ctx Context) (NewTotalPacketsSent uint32, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANCommonInterfaceConfig1).GetWANAccessProviderCtx(ctx Context) (NewWANAccessProvider string, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANCommonInterfaceConfig1).SetEnabledForInternetCtx(ctx Context, NewEnabledForInternet bool) (err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANDSLLinkConfig1).GetATMEncapsulationCtx(ctx Context) (NewATMEncapsulation string, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANDSLLinkConfig1).GetAutoConfigCtx(ctx Context) (NewAutoConfig bool, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANDSLLinkConfig1).GetDestinationAddressCtx(ctx Context) (NewDestinationAddress string, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANDSLLinkConfig1).GetDSLLinkInfoCtx(ctx Context) (NewLinkType string, NewLinkStatus string, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANDSLLinkConfig1).GetFCSPreservedCtx(ctx Context) (NewFCSPreserved bool, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANDSLLinkConfig1).GetModulationTypeCtx(ctx Context) (NewModulationType string, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANDSLLinkConfig1).SetATMEncapsulationCtx(ctx Context, NewATMEncapsulation string) (err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANDSLLinkConfig1).SetDestinationAddressCtx(ctx Context, NewDestinationAddress string) (err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANDSLLinkConfig1).SetDSLLinkTypeCtx(ctx Context, NewLinkType string) (err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANDSLLinkConfig1).SetFCSPreservedCtx(ctx Context, NewFCSPreserved bool) (err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANEthernetLinkConfig1).GetEthernetLinkStatusCtx(ctx Context) (NewEthernetLinkStatus string, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANIPConnection1).AddPortMappingCtx(ctx Context, NewRemoteHost string, NewExternalPort uint16, NewProtocol string, NewInternalPort uint16, NewInternalClient string, NewEnabled bool, NewPortMappingDescription string, NewLeaseDuration uint32) (err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANIPConnection1).DeletePortMappingCtx(ctx Context, NewRemoteHost string, NewExternalPort uint16, NewProtocol string) (err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANIPConnection1).ForceTerminationCtx(ctx Context) (err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANIPConnection1).GetAutoDisconnectTimeCtx(ctx Context) (NewAutoDisconnectTime uint32, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANIPConnection1).GetConnectionTypeInfoCtx(ctx Context) (NewConnectionType string, NewPossibleConnectionTypes string, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANIPConnection1).GetExternalIPAddressCtx(ctx Context) (NewExternalIPAddress string, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANIPConnection1).GetGenericPortMappingEntryCtx(ctx Context, NewPortMappingIndex uint16) (NewRemoteHost string, NewExternalPort uint16, NewProtocol string, NewInternalPort uint16, NewInternalClient string, NewEnabled bool, NewPortMappingDescription string, NewLeaseDuration uint32, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANIPConnection1).GetIdleDisconnectTimeCtx(ctx Context) (NewIdleDisconnectTime uint32, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANIPConnection1).GetNATRSIPStatusCtx(ctx Context) (NewRSIPAvailable bool, NewNATEnabled bool, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANIPConnection1).GetSpecificPortMappingEntryCtx(ctx Context, NewRemoteHost string, NewExternalPort uint16, NewProtocol string) (NewInternalPort uint16, NewInternalClient string, NewEnabled bool, NewPortMappingDescription string, NewLeaseDuration uint32, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANIPConnection1).GetStatusInfoCtx(ctx Context) (NewConnectionStatus string, NewLastConnectionError string, NewUptime uint32, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANIPConnection1).GetWarnDisconnectDelayCtx(ctx Context) (NewWarnDisconnectDelay uint32, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANIPConnection1).RequestConnectionCtx(ctx Context) (err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANIPConnection1).RequestTerminationCtx(ctx Context) (err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANIPConnection1).SetAutoDisconnectTimeCtx(ctx Context, NewAutoDisconnectTime uint32) (err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANIPConnection1).SetConnectionTypeCtx(ctx Context, NewConnectionType string) (err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANIPConnection1).SetIdleDisconnectTimeCtx(ctx Context, NewIdleDisconnectTime uint32) (err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANIPConnection1).SetWarnDisconnectDelayCtx(ctx Context, NewWarnDisconnectDelay uint32) (err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANPOTSLinkConfig1).GetCallRetryInfoCtx(ctx Context) (NewNumberOfRetries uint32, NewDelayBetweenRetries uint32, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANPOTSLinkConfig1).GetDataCompressionCtx(ctx Context) (NewDataCompression string, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANPOTSLinkConfig1).GetDataModulationSupportedCtx(ctx Context) (NewDataModulationSupported string, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANPOTSLinkConfig1).GetDataProtocolCtx(ctx Context) (NewDataProtocol string, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANPOTSLinkConfig1).GetFclassCtx(ctx Context) (NewFclass string, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANPOTSLinkConfig1).GetISPInfoCtx(ctx Context) (NewISPPhoneNumber string, NewISPInfo string, NewLinkType string, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANPOTSLinkConfig1).GetPlusVTRCommandSupportedCtx(ctx Context) (NewPlusVTRCommandSupported bool, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANPOTSLinkConfig1).SetCallRetryInfoCtx(ctx Context, NewNumberOfRetries uint32, NewDelayBetweenRetries uint32) (err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANPOTSLinkConfig1).SetISPInfoCtx(ctx Context, NewISPPhoneNumber string, NewISPInfo string, NewLinkType string) (err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANPPPConnection1).AddPortMappingCtx(ctx Context, NewRemoteHost string, NewExternalPort uint16, NewProtocol string, NewInternalPort uint16, NewInternalClient string, NewEnabled bool, NewPortMappingDescription string, NewLeaseDuration uint32) (err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANPPPConnection1).ConfigureConnectionCtx(ctx Context, NewUserName string, NewPassword string) (err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANPPPConnection1).DeletePortMappingCtx(ctx Context, NewRemoteHost string, NewExternalPort uint16, NewProtocol string) (err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANPPPConnection1).ForceTerminationCtx(ctx Context) (err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANPPPConnection1).GetAutoDisconnectTimeCtx(ctx Context) (NewAutoDisconnectTime uint32, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANPPPConnection1).GetConnectionTypeInfoCtx(ctx Context) (NewConnectionType string, NewPossibleConnectionTypes string, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANPPPConnection1).GetExternalIPAddressCtx(ctx Context) (NewExternalIPAddress string, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANPPPConnection1).GetGenericPortMappingEntryCtx(ctx Context, NewPortMappingIndex uint16) (NewRemoteHost string, NewExternalPort uint16, NewProtocol string, NewInternalPort uint16, NewInternalClient string, NewEnabled bool, NewPortMappingDescription string, NewLeaseDuration uint32, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANPPPConnection1).GetIdleDisconnectTimeCtx(ctx Context) (NewIdleDisconnectTime uint32, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANPPPConnection1).GetLinkLayerMaxBitRatesCtx(ctx Context) (NewUpstreamMaxBitRate uint32, NewDownstreamMaxBitRate uint32, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANPPPConnection1).GetNATRSIPStatusCtx(ctx Context) (NewRSIPAvailable bool, NewNATEnabled bool, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANPPPConnection1).GetPasswordCtx(ctx Context) (NewPassword string, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANPPPConnection1).GetPPPAuthenticationProtocolCtx(ctx Context) (NewPPPAuthenticationProtocol string, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANPPPConnection1).GetPPPCompressionProtocolCtx(ctx Context) (NewPPPCompressionProtocol string, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANPPPConnection1).GetPPPEncryptionProtocolCtx(ctx Context) (NewPPPEncryptionProtocol string, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANPPPConnection1).GetSpecificPortMappingEntryCtx(ctx Context, NewRemoteHost string, NewExternalPort uint16, NewProtocol string) (NewInternalPort uint16, NewInternalClient string, NewEnabled bool, NewPortMappingDescription string, NewLeaseDuration uint32, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANPPPConnection1).GetStatusInfoCtx(ctx Context) (NewConnectionStatus string, NewLastConnectionError string, NewUptime uint32, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANPPPConnection1).GetUserNameCtx(ctx Context) (NewUserName string, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANPPPConnection1).GetWarnDisconnectDelayCtx(ctx Context) (NewWarnDisconnectDelay uint32, err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANPPPConnection1).RequestConnectionCtx(ctx Context) (err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANPPPConnection1).RequestTerminationCtx(ctx Context) (err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANPPPConnection1).SetAutoDisconnectTimeCtx(ctx Context, NewAutoDisconnectTime uint32) (err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANPPPConnection1).SetConnectionTypeCtx(ctx Context, NewConnectionType string) (err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANPPPConnection1).SetIdleDisconnectTimeCtx(ctx Context, NewIdleDisconnectTime uint32) (err error) func github.com/huin/goupnp/dcps/internetgateway1.(*WANPPPConnection1).SetWarnDisconnectDelayCtx(ctx Context, NewWarnDisconnectDelay uint32) (err error) func github.com/huin/goupnp/dcps/internetgateway2.NewDeviceProtection1ClientsByURLCtx(ctx Context, loc *url.URL) ([]*internetgateway2.DeviceProtection1, error) func github.com/huin/goupnp/dcps/internetgateway2.NewDeviceProtection1ClientsCtx(ctx Context) (clients []*internetgateway2.DeviceProtection1, errors []error, err error) func github.com/huin/goupnp/dcps/internetgateway2.NewLANHostConfigManagement1ClientsByURLCtx(ctx Context, loc *url.URL) ([]*internetgateway2.LANHostConfigManagement1, error) func github.com/huin/goupnp/dcps/internetgateway2.NewLANHostConfigManagement1ClientsCtx(ctx Context) (clients []*internetgateway2.LANHostConfigManagement1, errors []error, err error) func github.com/huin/goupnp/dcps/internetgateway2.NewLayer3Forwarding1ClientsByURLCtx(ctx Context, loc *url.URL) ([]*internetgateway2.Layer3Forwarding1, error) func github.com/huin/goupnp/dcps/internetgateway2.NewLayer3Forwarding1ClientsCtx(ctx Context) (clients []*internetgateway2.Layer3Forwarding1, errors []error, err error) func github.com/huin/goupnp/dcps/internetgateway2.NewWANCableLinkConfig1ClientsByURLCtx(ctx Context, loc *url.URL) ([]*internetgateway2.WANCableLinkConfig1, error) func github.com/huin/goupnp/dcps/internetgateway2.NewWANCableLinkConfig1ClientsCtx(ctx Context) (clients []*internetgateway2.WANCableLinkConfig1, errors []error, err error) func github.com/huin/goupnp/dcps/internetgateway2.NewWANCommonInterfaceConfig1ClientsByURLCtx(ctx Context, loc *url.URL) ([]*internetgateway2.WANCommonInterfaceConfig1, error) func github.com/huin/goupnp/dcps/internetgateway2.NewWANCommonInterfaceConfig1ClientsCtx(ctx Context) (clients []*internetgateway2.WANCommonInterfaceConfig1, errors []error, err error) func github.com/huin/goupnp/dcps/internetgateway2.NewWANDSLLinkConfig1ClientsByURLCtx(ctx Context, loc *url.URL) ([]*internetgateway2.WANDSLLinkConfig1, error) func github.com/huin/goupnp/dcps/internetgateway2.NewWANDSLLinkConfig1ClientsCtx(ctx Context) (clients []*internetgateway2.WANDSLLinkConfig1, errors []error, err error) func github.com/huin/goupnp/dcps/internetgateway2.NewWANEthernetLinkConfig1ClientsByURLCtx(ctx Context, loc *url.URL) ([]*internetgateway2.WANEthernetLinkConfig1, error) func github.com/huin/goupnp/dcps/internetgateway2.NewWANEthernetLinkConfig1ClientsCtx(ctx Context) (clients []*internetgateway2.WANEthernetLinkConfig1, errors []error, err error) func github.com/huin/goupnp/dcps/internetgateway2.NewWANIPConnection1ClientsByURLCtx(ctx Context, loc *url.URL) ([]*internetgateway2.WANIPConnection1, error) func github.com/huin/goupnp/dcps/internetgateway2.NewWANIPConnection1ClientsCtx(ctx Context) (clients []*internetgateway2.WANIPConnection1, errors []error, err error) func github.com/huin/goupnp/dcps/internetgateway2.NewWANIPConnection2ClientsByURLCtx(ctx Context, loc *url.URL) ([]*internetgateway2.WANIPConnection2, error) func github.com/huin/goupnp/dcps/internetgateway2.NewWANIPConnection2ClientsCtx(ctx Context) (clients []*internetgateway2.WANIPConnection2, errors []error, err error) func github.com/huin/goupnp/dcps/internetgateway2.NewWANIPv6FirewallControl1ClientsByURLCtx(ctx Context, loc *url.URL) ([]*internetgateway2.WANIPv6FirewallControl1, error) func github.com/huin/goupnp/dcps/internetgateway2.NewWANIPv6FirewallControl1ClientsCtx(ctx Context) (clients []*internetgateway2.WANIPv6FirewallControl1, errors []error, err error) func github.com/huin/goupnp/dcps/internetgateway2.NewWANPOTSLinkConfig1ClientsByURLCtx(ctx Context, loc *url.URL) ([]*internetgateway2.WANPOTSLinkConfig1, error) func github.com/huin/goupnp/dcps/internetgateway2.NewWANPOTSLinkConfig1ClientsCtx(ctx Context) (clients []*internetgateway2.WANPOTSLinkConfig1, errors []error, err error) func github.com/huin/goupnp/dcps/internetgateway2.NewWANPPPConnection1ClientsByURLCtx(ctx Context, loc *url.URL) ([]*internetgateway2.WANPPPConnection1, error) func github.com/huin/goupnp/dcps/internetgateway2.NewWANPPPConnection1ClientsCtx(ctx Context) (clients []*internetgateway2.WANPPPConnection1, errors []error, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*DeviceProtection1).AddIdentityListCtx(ctx Context, IdentityList string) (IdentityListResult string, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*DeviceProtection1).AddRolesForIdentityCtx(ctx Context, Identity string, RoleList string) (err error) func github.com/huin/goupnp/dcps/internetgateway2.(*DeviceProtection1).GetACLDataCtx(ctx Context) (ACL string, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*DeviceProtection1).GetAssignedRolesCtx(ctx Context) (RoleList string, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*DeviceProtection1).GetRolesForActionCtx(ctx Context, DeviceUDN string, ServiceId string, ActionName string) (RoleList string, RestrictedRoleList string, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*DeviceProtection1).GetSupportedProtocolsCtx(ctx Context) (ProtocolList string, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*DeviceProtection1).GetUserLoginChallengeCtx(ctx Context, ProtocolType string, Name string) (Salt []byte, Challenge []byte, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*DeviceProtection1).RemoveIdentityCtx(ctx Context, Identity string) (err error) func github.com/huin/goupnp/dcps/internetgateway2.(*DeviceProtection1).RemoveRolesForIdentityCtx(ctx Context, Identity string, RoleList string) (err error) func github.com/huin/goupnp/dcps/internetgateway2.(*DeviceProtection1).SendSetupMessageCtx(ctx Context, ProtocolType string, InMessage []byte) (OutMessage []byte, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*DeviceProtection1).SetUserLoginPasswordCtx(ctx Context, ProtocolType string, Name string, Stored []byte, Salt []byte) (err error) func github.com/huin/goupnp/dcps/internetgateway2.(*DeviceProtection1).UserLoginCtx(ctx Context, ProtocolType string, Challenge []byte, Authenticator []byte) (err error) func github.com/huin/goupnp/dcps/internetgateway2.(*DeviceProtection1).UserLogoutCtx(ctx Context) (err error) func github.com/huin/goupnp/dcps/internetgateway2.(*LANHostConfigManagement1).DeleteDNSServerCtx(ctx Context, NewDNSServers string) (err error) func github.com/huin/goupnp/dcps/internetgateway2.(*LANHostConfigManagement1).DeleteIPRouterCtx(ctx Context, NewIPRouters string) (err error) func github.com/huin/goupnp/dcps/internetgateway2.(*LANHostConfigManagement1).DeleteReservedAddressCtx(ctx Context, NewReservedAddresses string) (err error) func github.com/huin/goupnp/dcps/internetgateway2.(*LANHostConfigManagement1).GetAddressRangeCtx(ctx Context) (NewMinAddress string, NewMaxAddress string, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*LANHostConfigManagement1).GetDHCPRelayCtx(ctx Context) (NewDHCPRelay bool, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*LANHostConfigManagement1).GetDHCPServerConfigurableCtx(ctx Context) (NewDHCPServerConfigurable bool, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*LANHostConfigManagement1).GetDNSServersCtx(ctx Context) (NewDNSServers string, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*LANHostConfigManagement1).GetDomainNameCtx(ctx Context) (NewDomainName string, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*LANHostConfigManagement1).GetIPRoutersListCtx(ctx Context) (NewIPRouters string, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*LANHostConfigManagement1).GetReservedAddressesCtx(ctx Context) (NewReservedAddresses string, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*LANHostConfigManagement1).GetSubnetMaskCtx(ctx Context) (NewSubnetMask string, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*LANHostConfigManagement1).SetAddressRangeCtx(ctx Context, NewMinAddress string, NewMaxAddress string) (err error) func github.com/huin/goupnp/dcps/internetgateway2.(*LANHostConfigManagement1).SetDHCPRelayCtx(ctx Context, NewDHCPRelay bool) (err error) func github.com/huin/goupnp/dcps/internetgateway2.(*LANHostConfigManagement1).SetDHCPServerConfigurableCtx(ctx Context, NewDHCPServerConfigurable bool) (err error) func github.com/huin/goupnp/dcps/internetgateway2.(*LANHostConfigManagement1).SetDNSServerCtx(ctx Context, NewDNSServers string) (err error) func github.com/huin/goupnp/dcps/internetgateway2.(*LANHostConfigManagement1).SetDomainNameCtx(ctx Context, NewDomainName string) (err error) func github.com/huin/goupnp/dcps/internetgateway2.(*LANHostConfigManagement1).SetIPRouterCtx(ctx Context, NewIPRouters string) (err error) func github.com/huin/goupnp/dcps/internetgateway2.(*LANHostConfigManagement1).SetReservedAddressCtx(ctx Context, NewReservedAddresses string) (err error) func github.com/huin/goupnp/dcps/internetgateway2.(*LANHostConfigManagement1).SetSubnetMaskCtx(ctx Context, NewSubnetMask string) (err error) func github.com/huin/goupnp/dcps/internetgateway2.(*Layer3Forwarding1).GetDefaultConnectionServiceCtx(ctx Context) (NewDefaultConnectionService string, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*Layer3Forwarding1).SetDefaultConnectionServiceCtx(ctx Context, NewDefaultConnectionService string) (err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANCableLinkConfig1).GetBPIEncryptionEnabledCtx(ctx Context) (NewBPIEncryptionEnabled bool, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANCableLinkConfig1).GetCableLinkConfigInfoCtx(ctx Context) (NewCableLinkConfigState string, NewLinkType string, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANCableLinkConfig1).GetConfigFileCtx(ctx Context) (NewConfigFile string, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANCableLinkConfig1).GetDownstreamFrequencyCtx(ctx Context) (NewDownstreamFrequency uint32, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANCableLinkConfig1).GetDownstreamModulationCtx(ctx Context) (NewDownstreamModulation string, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANCableLinkConfig1).GetTFTPServerCtx(ctx Context) (NewTFTPServer string, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANCableLinkConfig1).GetUpstreamChannelIDCtx(ctx Context) (NewUpstreamChannelID uint32, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANCableLinkConfig1).GetUpstreamFrequencyCtx(ctx Context) (NewUpstreamFrequency uint32, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANCableLinkConfig1).GetUpstreamModulationCtx(ctx Context) (NewUpstreamModulation string, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANCableLinkConfig1).GetUpstreamPowerLevelCtx(ctx Context) (NewUpstreamPowerLevel uint32, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANCommonInterfaceConfig1).GetActiveConnectionCtx(ctx Context, NewActiveConnectionIndex uint16) (NewActiveConnDeviceContainer string, NewActiveConnectionServiceID string, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANCommonInterfaceConfig1).GetCommonLinkPropertiesCtx(ctx Context) (NewWANAccessType string, NewLayer1UpstreamMaxBitRate uint32, NewLayer1DownstreamMaxBitRate uint32, NewPhysicalLinkStatus string, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANCommonInterfaceConfig1).GetEnabledForInternetCtx(ctx Context) (NewEnabledForInternet bool, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANCommonInterfaceConfig1).GetMaximumActiveConnectionsCtx(ctx Context) (NewMaximumActiveConnections uint16, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANCommonInterfaceConfig1).GetTotalBytesReceivedCtx(ctx Context) (NewTotalBytesReceived uint64, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANCommonInterfaceConfig1).GetTotalBytesSentCtx(ctx Context) (NewTotalBytesSent uint64, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANCommonInterfaceConfig1).GetTotalPacketsReceivedCtx(ctx Context) (NewTotalPacketsReceived uint32, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANCommonInterfaceConfig1).GetTotalPacketsSentCtx(ctx Context) (NewTotalPacketsSent uint32, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANCommonInterfaceConfig1).GetWANAccessProviderCtx(ctx Context) (NewWANAccessProvider string, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANCommonInterfaceConfig1).SetEnabledForInternetCtx(ctx Context, NewEnabledForInternet bool) (err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANDSLLinkConfig1).GetATMEncapsulationCtx(ctx Context) (NewATMEncapsulation string, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANDSLLinkConfig1).GetAutoConfigCtx(ctx Context) (NewAutoConfig bool, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANDSLLinkConfig1).GetDestinationAddressCtx(ctx Context) (NewDestinationAddress string, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANDSLLinkConfig1).GetDSLLinkInfoCtx(ctx Context) (NewLinkType string, NewLinkStatus string, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANDSLLinkConfig1).GetFCSPreservedCtx(ctx Context) (NewFCSPreserved bool, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANDSLLinkConfig1).GetModulationTypeCtx(ctx Context) (NewModulationType string, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANDSLLinkConfig1).SetATMEncapsulationCtx(ctx Context, NewATMEncapsulation string) (err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANDSLLinkConfig1).SetDestinationAddressCtx(ctx Context, NewDestinationAddress string) (err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANDSLLinkConfig1).SetDSLLinkTypeCtx(ctx Context, NewLinkType string) (err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANDSLLinkConfig1).SetFCSPreservedCtx(ctx Context, NewFCSPreserved bool) (err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANEthernetLinkConfig1).GetEthernetLinkStatusCtx(ctx Context) (NewEthernetLinkStatus string, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANIPConnection1).AddPortMappingCtx(ctx Context, NewRemoteHost string, NewExternalPort uint16, NewProtocol string, NewInternalPort uint16, NewInternalClient string, NewEnabled bool, NewPortMappingDescription string, NewLeaseDuration uint32) (err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANIPConnection1).DeletePortMappingCtx(ctx Context, NewRemoteHost string, NewExternalPort uint16, NewProtocol string) (err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANIPConnection1).ForceTerminationCtx(ctx Context) (err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANIPConnection1).GetAutoDisconnectTimeCtx(ctx Context) (NewAutoDisconnectTime uint32, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANIPConnection1).GetConnectionTypeInfoCtx(ctx Context) (NewConnectionType string, NewPossibleConnectionTypes string, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANIPConnection1).GetExternalIPAddressCtx(ctx Context) (NewExternalIPAddress string, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANIPConnection1).GetGenericPortMappingEntryCtx(ctx Context, NewPortMappingIndex uint16) (NewRemoteHost string, NewExternalPort uint16, NewProtocol string, NewInternalPort uint16, NewInternalClient string, NewEnabled bool, NewPortMappingDescription string, NewLeaseDuration uint32, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANIPConnection1).GetIdleDisconnectTimeCtx(ctx Context) (NewIdleDisconnectTime uint32, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANIPConnection1).GetNATRSIPStatusCtx(ctx Context) (NewRSIPAvailable bool, NewNATEnabled bool, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANIPConnection1).GetSpecificPortMappingEntryCtx(ctx Context, NewRemoteHost string, NewExternalPort uint16, NewProtocol string) (NewInternalPort uint16, NewInternalClient string, NewEnabled bool, NewPortMappingDescription string, NewLeaseDuration uint32, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANIPConnection1).GetStatusInfoCtx(ctx Context) (NewConnectionStatus string, NewLastConnectionError string, NewUptime uint32, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANIPConnection1).GetWarnDisconnectDelayCtx(ctx Context) (NewWarnDisconnectDelay uint32, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANIPConnection1).RequestConnectionCtx(ctx Context) (err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANIPConnection1).RequestTerminationCtx(ctx Context) (err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANIPConnection1).SetAutoDisconnectTimeCtx(ctx Context, NewAutoDisconnectTime uint32) (err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANIPConnection1).SetConnectionTypeCtx(ctx Context, NewConnectionType string) (err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANIPConnection1).SetIdleDisconnectTimeCtx(ctx Context, NewIdleDisconnectTime uint32) (err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANIPConnection1).SetWarnDisconnectDelayCtx(ctx Context, NewWarnDisconnectDelay uint32) (err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANIPConnection2).AddAnyPortMappingCtx(ctx Context, NewRemoteHost string, NewExternalPort uint16, NewProtocol string, NewInternalPort uint16, NewInternalClient string, NewEnabled bool, NewPortMappingDescription string, NewLeaseDuration uint32) (NewReservedPort uint16, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANIPConnection2).AddPortMappingCtx(ctx Context, NewRemoteHost string, NewExternalPort uint16, NewProtocol string, NewInternalPort uint16, NewInternalClient string, NewEnabled bool, NewPortMappingDescription string, NewLeaseDuration uint32) (err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANIPConnection2).DeletePortMappingCtx(ctx Context, NewRemoteHost string, NewExternalPort uint16, NewProtocol string) (err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANIPConnection2).DeletePortMappingRangeCtx(ctx Context, NewStartPort uint16, NewEndPort uint16, NewProtocol string, NewManage bool) (err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANIPConnection2).ForceTerminationCtx(ctx Context) (err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANIPConnection2).GetAutoDisconnectTimeCtx(ctx Context) (NewAutoDisconnectTime uint32, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANIPConnection2).GetConnectionTypeInfoCtx(ctx Context) (NewConnectionType string, NewPossibleConnectionTypes string, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANIPConnection2).GetExternalIPAddressCtx(ctx Context) (NewExternalIPAddress string, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANIPConnection2).GetGenericPortMappingEntryCtx(ctx Context, NewPortMappingIndex uint16) (NewRemoteHost string, NewExternalPort uint16, NewProtocol string, NewInternalPort uint16, NewInternalClient string, NewEnabled bool, NewPortMappingDescription string, NewLeaseDuration uint32, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANIPConnection2).GetIdleDisconnectTimeCtx(ctx Context) (NewIdleDisconnectTime uint32, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANIPConnection2).GetListOfPortMappingsCtx(ctx Context, NewStartPort uint16, NewEndPort uint16, NewProtocol string, NewManage bool, NewNumberOfPorts uint16) (NewPortListing string, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANIPConnection2).GetNATRSIPStatusCtx(ctx Context) (NewRSIPAvailable bool, NewNATEnabled bool, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANIPConnection2).GetSpecificPortMappingEntryCtx(ctx Context, NewRemoteHost string, NewExternalPort uint16, NewProtocol string) (NewInternalPort uint16, NewInternalClient string, NewEnabled bool, NewPortMappingDescription string, NewLeaseDuration uint32, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANIPConnection2).GetStatusInfoCtx(ctx Context) (NewConnectionStatus string, NewLastConnectionError string, NewUptime uint32, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANIPConnection2).GetWarnDisconnectDelayCtx(ctx Context) (NewWarnDisconnectDelay uint32, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANIPConnection2).RequestConnectionCtx(ctx Context) (err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANIPConnection2).RequestTerminationCtx(ctx Context) (err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANIPConnection2).SetAutoDisconnectTimeCtx(ctx Context, NewAutoDisconnectTime uint32) (err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANIPConnection2).SetConnectionTypeCtx(ctx Context, NewConnectionType string) (err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANIPConnection2).SetIdleDisconnectTimeCtx(ctx Context, NewIdleDisconnectTime uint32) (err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANIPConnection2).SetWarnDisconnectDelayCtx(ctx Context, NewWarnDisconnectDelay uint32) (err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANIPv6FirewallControl1).AddPinholeCtx(ctx Context, RemoteHost string, RemotePort uint16, InternalClient string, InternalPort uint16, Protocol uint16, LeaseTime uint32) (UniqueID uint16, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANIPv6FirewallControl1).CheckPinholeWorkingCtx(ctx Context, UniqueID uint16) (IsWorking bool, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANIPv6FirewallControl1).DeletePinholeCtx(ctx Context, UniqueID uint16) (err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANIPv6FirewallControl1).GetFirewallStatusCtx(ctx Context) (FirewallEnabled bool, InboundPinholeAllowed bool, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANIPv6FirewallControl1).GetOutboundPinholeTimeoutCtx(ctx Context, RemoteHost string, RemotePort uint16, InternalClient string, InternalPort uint16, Protocol uint16) (OutboundPinholeTimeout uint32, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANIPv6FirewallControl1).GetPinholePacketsCtx(ctx Context, UniqueID uint16) (PinholePackets uint32, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANIPv6FirewallControl1).UpdatePinholeCtx(ctx Context, UniqueID uint16, NewLeaseTime uint32) (err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANPOTSLinkConfig1).GetCallRetryInfoCtx(ctx Context) (NewNumberOfRetries uint32, NewDelayBetweenRetries uint32, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANPOTSLinkConfig1).GetDataCompressionCtx(ctx Context) (NewDataCompression string, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANPOTSLinkConfig1).GetDataModulationSupportedCtx(ctx Context) (NewDataModulationSupported string, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANPOTSLinkConfig1).GetDataProtocolCtx(ctx Context) (NewDataProtocol string, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANPOTSLinkConfig1).GetFclassCtx(ctx Context) (NewFclass string, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANPOTSLinkConfig1).GetISPInfoCtx(ctx Context) (NewISPPhoneNumber string, NewISPInfo string, NewLinkType string, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANPOTSLinkConfig1).GetPlusVTRCommandSupportedCtx(ctx Context) (NewPlusVTRCommandSupported bool, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANPOTSLinkConfig1).SetCallRetryInfoCtx(ctx Context, NewNumberOfRetries uint32, NewDelayBetweenRetries uint32) (err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANPOTSLinkConfig1).SetISPInfoCtx(ctx Context, NewISPPhoneNumber string, NewISPInfo string, NewLinkType string) (err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANPPPConnection1).AddPortMappingCtx(ctx Context, NewRemoteHost string, NewExternalPort uint16, NewProtocol string, NewInternalPort uint16, NewInternalClient string, NewEnabled bool, NewPortMappingDescription string, NewLeaseDuration uint32) (err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANPPPConnection1).ConfigureConnectionCtx(ctx Context, NewUserName string, NewPassword string) (err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANPPPConnection1).DeletePortMappingCtx(ctx Context, NewRemoteHost string, NewExternalPort uint16, NewProtocol string) (err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANPPPConnection1).ForceTerminationCtx(ctx Context) (err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANPPPConnection1).GetAutoDisconnectTimeCtx(ctx Context) (NewAutoDisconnectTime uint32, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANPPPConnection1).GetConnectionTypeInfoCtx(ctx Context) (NewConnectionType string, NewPossibleConnectionTypes string, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANPPPConnection1).GetExternalIPAddressCtx(ctx Context) (NewExternalIPAddress string, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANPPPConnection1).GetGenericPortMappingEntryCtx(ctx Context, NewPortMappingIndex uint16) (NewRemoteHost string, NewExternalPort uint16, NewProtocol string, NewInternalPort uint16, NewInternalClient string, NewEnabled bool, NewPortMappingDescription string, NewLeaseDuration uint32, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANPPPConnection1).GetIdleDisconnectTimeCtx(ctx Context) (NewIdleDisconnectTime uint32, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANPPPConnection1).GetLinkLayerMaxBitRatesCtx(ctx Context) (NewUpstreamMaxBitRate uint32, NewDownstreamMaxBitRate uint32, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANPPPConnection1).GetNATRSIPStatusCtx(ctx Context) (NewRSIPAvailable bool, NewNATEnabled bool, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANPPPConnection1).GetPasswordCtx(ctx Context) (NewPassword string, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANPPPConnection1).GetPPPAuthenticationProtocolCtx(ctx Context) (NewPPPAuthenticationProtocol string, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANPPPConnection1).GetPPPCompressionProtocolCtx(ctx Context) (NewPPPCompressionProtocol string, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANPPPConnection1).GetPPPEncryptionProtocolCtx(ctx Context) (NewPPPEncryptionProtocol string, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANPPPConnection1).GetSpecificPortMappingEntryCtx(ctx Context, NewRemoteHost string, NewExternalPort uint16, NewProtocol string) (NewInternalPort uint16, NewInternalClient string, NewEnabled bool, NewPortMappingDescription string, NewLeaseDuration uint32, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANPPPConnection1).GetStatusInfoCtx(ctx Context) (NewConnectionStatus string, NewLastConnectionError string, NewUptime uint32, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANPPPConnection1).GetUserNameCtx(ctx Context) (NewUserName string, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANPPPConnection1).GetWarnDisconnectDelayCtx(ctx Context) (NewWarnDisconnectDelay uint32, err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANPPPConnection1).RequestConnectionCtx(ctx Context) (err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANPPPConnection1).RequestTerminationCtx(ctx Context) (err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANPPPConnection1).SetAutoDisconnectTimeCtx(ctx Context, NewAutoDisconnectTime uint32) (err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANPPPConnection1).SetConnectionTypeCtx(ctx Context, NewConnectionType string) (err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANPPPConnection1).SetIdleDisconnectTimeCtx(ctx Context, NewIdleDisconnectTime uint32) (err error) func github.com/huin/goupnp/dcps/internetgateway2.(*WANPPPConnection1).SetWarnDisconnectDelayCtx(ctx Context, NewWarnDisconnectDelay uint32) (err error) func github.com/huin/goupnp/soap.(*SOAPClient).PerformActionCtx(ctx Context, actionNamespace, actionName string, inAction interface{}, outAction interface{}) error func github.com/huin/goupnp/ssdp.RawSearch(ctx Context, httpu ssdp.HTTPUClientCtx, searchTarget string, numSends int) ([]*http.Response, error) func github.com/huin/goupnp/ssdp.SSDPRawSearchCtx(ctx Context, httpu ssdp.HTTPUClient, searchTarget string, maxWaitSeconds int, numSends int) ([]*http.Response, error) func github.com/K-Phoen/grabana.(*Client).AddAlert(ctx Context, namespace string, alertDefinition alert.Alert, datasourcesMap map[string]string) error func github.com/K-Phoen/grabana.(*Client).APIKeys(ctx Context) (map[string]grabana.APIKey, error) func github.com/K-Phoen/grabana.(*Client).ConfigureAlertManager(ctx Context, manager *alertmanager.Manager) error func github.com/K-Phoen/grabana.(*Client).CreateAPIKey(ctx Context, request grabana.CreateAPIKeyRequest) (string, error) func github.com/K-Phoen/grabana.(*Client).CreateFolder(ctx Context, name string) (*grabana.Folder, error) func github.com/K-Phoen/grabana.(*Client).DeleteAlertGroup(ctx Context, namespace string, groupName string) error func github.com/K-Phoen/grabana.(*Client).DeleteAPIKeyByName(ctx Context, name string) error func github.com/K-Phoen/grabana.(*Client).DeleteDashboard(ctx Context, uid string) error func github.com/K-Phoen/grabana.(*Client).DeleteDatasource(ctx Context, name string) error func github.com/K-Phoen/grabana.(*Client).FindOrCreateFolder(ctx Context, name string) (*grabana.Folder, error) func github.com/K-Phoen/grabana.(*Client).GetDashboardByTitle(ctx Context, title string) (*grabana.Dashboard, error) func github.com/K-Phoen/grabana.(*Client).GetDatasourceUIDByName(ctx Context, name string) (string, error) func github.com/K-Phoen/grabana.(*Client).GetFolderByTitle(ctx Context, title string) (*grabana.Folder, error) func github.com/K-Phoen/grabana.(*Client).UpsertDashboard(ctx Context, folder *grabana.Folder, builder dashboard.Builder) (*grabana.Dashboard, error) func github.com/K-Phoen/grabana.(*Client).UpsertDatasource(ctx Context, datasource datasource.Datasource) error func github.com/libp2p/go-libp2p/core/connmgr.ConnManager.TrimOpenConns(ctx Context) func github.com/libp2p/go-libp2p/core/connmgr.NullConnMgr.TrimOpenConns(_ Context) func github.com/libp2p/go-libp2p/core/discovery.Advertiser.Advertise(ctx Context, ns string, opts ...discovery.Option) (time.Duration, error) func github.com/libp2p/go-libp2p/core/discovery.Discoverer.FindPeers(ctx Context, ns string, opts ...discovery.Option) (<-chan peer.AddrInfo, error) func github.com/libp2p/go-libp2p/core/discovery.Discovery.Advertise(ctx Context, ns string, opts ...discovery.Option) (time.Duration, error) func github.com/libp2p/go-libp2p/core/discovery.Discovery.FindPeers(ctx Context, ns string, opts ...discovery.Option) (<-chan peer.AddrInfo, error) func github.com/libp2p/go-libp2p/core/host.Host.Connect(ctx Context, pi peer.AddrInfo) error func github.com/libp2p/go-libp2p/core/host.Host.NewStream(ctx Context, p peer.ID, pids ...protocol.ID) (network.Stream, error) func github.com/libp2p/go-libp2p/core/network.GetAllowLimitedConn(ctx Context) (usetransient bool, reason string) func github.com/libp2p/go-libp2p/core/network.GetDialPeerTimeout(ctx Context) time.Duration func github.com/libp2p/go-libp2p/core/network.GetForceDirectDial(ctx Context) (forceDirect bool, reason string) func github.com/libp2p/go-libp2p/core/network.GetNoDial(ctx Context) (nodial bool, reason string) func github.com/libp2p/go-libp2p/core/network.GetSimultaneousConnect(ctx Context) (simconnect bool, isClient bool, reason string) func github.com/libp2p/go-libp2p/core/network.GetUseTransient(ctx Context) (usetransient bool, reason string) func github.com/libp2p/go-libp2p/core/network.UnwrapConnManagementScope(ctx Context) (network.ConnManagementScope, error) func github.com/libp2p/go-libp2p/core/network.WithAllowLimitedConn(ctx Context, reason string) Context func github.com/libp2p/go-libp2p/core/network.WithConnManagementScope(ctx Context, scope network.ConnManagementScope) Context func github.com/libp2p/go-libp2p/core/network.WithDialPeerTimeout(ctx Context, timeout time.Duration) Context func github.com/libp2p/go-libp2p/core/network.WithForceDirectDial(ctx Context, reason string) Context func github.com/libp2p/go-libp2p/core/network.WithNoDial(ctx Context, reason string) Context func github.com/libp2p/go-libp2p/core/network.WithSimultaneousConnect(ctx Context, isClient bool, reason string) Context func github.com/libp2p/go-libp2p/core/network.WithUseTransient(ctx Context, reason string) Context func github.com/libp2p/go-libp2p/core/network.Conn.NewStream(Context) (network.Stream, error) func github.com/libp2p/go-libp2p/core/network.Dialer.DialPeer(Context, peer.ID) (network.Conn, error) func github.com/libp2p/go-libp2p/core/network.MultiaddrDNSResolver.ResolveDNSAddr(ctx Context, expectedPeerID peer.ID, maddr ma.Multiaddr, recursionLimit, outputLimit int) ([]ma.Multiaddr, error) func github.com/libp2p/go-libp2p/core/network.MultiaddrDNSResolver.ResolveDNSComponent(ctx Context, maddr ma.Multiaddr, outputLimit int) ([]ma.Multiaddr, error) func github.com/libp2p/go-libp2p/core/network.MuxedConn.OpenStream(Context) (network.MuxedStream, error) func github.com/libp2p/go-libp2p/core/network.Network.DialPeer(Context, peer.ID) (network.Conn, error) func github.com/libp2p/go-libp2p/core/network.Network.NewStream(Context, peer.ID) (network.Stream, error) func github.com/libp2p/go-libp2p/core/peerstore.AddrBook.AddrStream(Context, peer.ID) <-chan ma.Multiaddr func github.com/libp2p/go-libp2p/core/peerstore.Peerstore.AddrStream(Context, peer.ID) <-chan ma.Multiaddr func github.com/libp2p/go-libp2p/core/routing.GetPublicKey(r routing.ValueStore, ctx Context, p peer.ID) (ci.PubKey, error) func github.com/libp2p/go-libp2p/core/routing.PublishQueryEvent(ctx Context, ev *routing.QueryEvent) func github.com/libp2p/go-libp2p/core/routing.RegisterForQueryEvents(ctx Context) (Context, <-chan *routing.QueryEvent) func github.com/libp2p/go-libp2p/core/routing.SubscribesToQueryEvents(ctx Context) bool func github.com/libp2p/go-libp2p/core/routing.ContentDiscovery.FindProvidersAsync(Context, cid.Cid, int) <-chan peer.AddrInfo func github.com/libp2p/go-libp2p/core/routing.ContentProviding.Provide(Context, cid.Cid, bool) error func github.com/libp2p/go-libp2p/core/routing.ContentRouting.FindProvidersAsync(Context, cid.Cid, int) <-chan peer.AddrInfo func github.com/libp2p/go-libp2p/core/routing.ContentRouting.Provide(Context, cid.Cid, bool) error func github.com/libp2p/go-libp2p/core/routing.PeerRouting.FindPeer(Context, peer.ID) (peer.AddrInfo, error) func github.com/libp2p/go-libp2p/core/routing.PubKeyFetcher.GetPublicKey(Context, peer.ID) (ci.PubKey, error) func github.com/libp2p/go-libp2p/core/routing.Routing.Bootstrap(Context) error func github.com/libp2p/go-libp2p/core/routing.Routing.FindPeer(Context, peer.ID) (peer.AddrInfo, error) func github.com/libp2p/go-libp2p/core/routing.Routing.FindProvidersAsync(Context, cid.Cid, int) <-chan peer.AddrInfo func github.com/libp2p/go-libp2p/core/routing.Routing.GetValue(Context, string, ...routing.Option) ([]byte, error) func github.com/libp2p/go-libp2p/core/routing.Routing.Provide(Context, cid.Cid, bool) error func github.com/libp2p/go-libp2p/core/routing.Routing.PutValue(Context, string, []byte, ...routing.Option) error func github.com/libp2p/go-libp2p/core/routing.Routing.SearchValue(Context, string, ...routing.Option) (<-chan []byte, error) func github.com/libp2p/go-libp2p/core/routing.ValueStore.GetValue(Context, string, ...routing.Option) ([]byte, error) func github.com/libp2p/go-libp2p/core/routing.ValueStore.PutValue(Context, string, []byte, ...routing.Option) error func github.com/libp2p/go-libp2p/core/routing.ValueStore.SearchValue(Context, string, ...routing.Option) (<-chan []byte, error) func github.com/libp2p/go-libp2p/core/sec.SecureTransport.SecureInbound(ctx Context, insecure net.Conn, p peer.ID) (sec.SecureConn, error) func github.com/libp2p/go-libp2p/core/sec.SecureTransport.SecureOutbound(ctx Context, insecure net.Conn, p peer.ID) (sec.SecureConn, error) func github.com/libp2p/go-libp2p/core/sec/insecure.(*Transport).SecureInbound(_ Context, insecure net.Conn, p peer.ID) (sec.SecureConn, error) func github.com/libp2p/go-libp2p/core/sec/insecure.(*Transport).SecureOutbound(_ Context, insecure net.Conn, p peer.ID) (sec.SecureConn, error) func github.com/libp2p/go-libp2p/core/transport.CapableConn.OpenStream(Context) (network.MuxedStream, error) func github.com/libp2p/go-libp2p/core/transport.DialUpdater.DialWithUpdates(Context, ma.Multiaddr, peer.ID, chan<- transport.DialUpdate) (transport.CapableConn, error) func github.com/libp2p/go-libp2p/core/transport.Resolver.Resolve(ctx Context, maddr ma.Multiaddr) ([]ma.Multiaddr, error) func github.com/libp2p/go-libp2p/core/transport.SkipResolver.SkipResolve(ctx Context, maddr ma.Multiaddr) bool func github.com/libp2p/go-libp2p/core/transport.Transport.Dial(ctx Context, raddr ma.Multiaddr, p peer.ID) (transport.CapableConn, error) func github.com/libp2p/go-libp2p/core/transport.TransportNetwork.DialPeer(Context, peer.ID) (network.Conn, error) func github.com/libp2p/go-libp2p/core/transport.TransportNetwork.NewStream(Context, peer.ID) (network.Stream, error) func github.com/libp2p/go-libp2p/core/transport.Upgrader.Upgrade(ctx Context, t transport.Transport, maconn manet.Conn, dir network.Direction, p peer.ID, scope network.ConnManagementScope) (transport.CapableConn, error) func github.com/libp2p/go-libp2p/p2p/discovery/backoff.(*BackoffConnector).Connect(ctx Context, peerCh <-chan peer.AddrInfo) func github.com/libp2p/go-libp2p/p2p/discovery/backoff.(*BackoffDiscovery).Advertise(ctx Context, ns string, opts ...discovery.Option) (time.Duration, error) func github.com/libp2p/go-libp2p/p2p/discovery/backoff.(*BackoffDiscovery).FindPeers(ctx Context, ns string, opts ...discovery.Option) (<-chan peer.AddrInfo, error) func github.com/libp2p/go-libp2p/p2p/host/autonat.Client.DialBack(ctx Context, p peer.ID) error func github.com/libp2p/go-libp2p/p2p/host/basic.(*BasicHost).Connect(ctx Context, pi peer.AddrInfo) error func github.com/libp2p/go-libp2p/p2p/host/basic.(*BasicHost).NewStream(ctx Context, p peer.ID, pids ...protocol.ID) (str network.Stream, strErr error) func github.com/libp2p/go-libp2p/p2p/host/blank.(*BlankHost).Connect(ctx Context, ai peer.AddrInfo) error func github.com/libp2p/go-libp2p/p2p/host/blank.(*BlankHost).NewStream(ctx Context, p peer.ID, protos ...protocol.ID) (network.Stream, error) func github.com/libp2p/go-libp2p/p2p/host/peerstore/pstoremem.(*AddrSubManager).AddrStream(ctx Context, p peer.ID, initial []ma.Multiaddr) <-chan ma.Multiaddr func github.com/libp2p/go-libp2p/p2p/host/routed.(*RoutedHost).Connect(ctx Context, pi peer.AddrInfo) error func github.com/libp2p/go-libp2p/p2p/host/routed.(*RoutedHost).NewStream(ctx Context, p peer.ID, pids ...protocol.ID) (network.Stream, error) func github.com/libp2p/go-libp2p/p2p/host/routed.Routing.FindPeer(Context, peer.ID) (peer.AddrInfo, error) func github.com/libp2p/go-libp2p/p2p/net/connmgr.(*BasicConnMgr).TrimOpenConns(_ Context) func github.com/libp2p/go-libp2p/p2p/net/nat.DiscoverNAT(ctx Context) (*nat.NAT, error) func github.com/libp2p/go-libp2p/p2p/net/nat.(*NAT).AddMapping(ctx Context, protocol string, port int) error func github.com/libp2p/go-libp2p/p2p/net/nat.(*NAT).RemoveMapping(ctx Context, protocol string, port int) error func github.com/libp2p/go-libp2p/p2p/net/nat/internal/nat.DiscoverGateway(ctx Context) (nat.NAT, error) func github.com/libp2p/go-libp2p/p2p/net/nat/internal/nat.NAT.AddPortMapping(ctx Context, protocol string, internalPort int, description string, timeout time.Duration) (mappedExternalPort int, err error) func github.com/libp2p/go-libp2p/p2p/net/nat/internal/nat.NAT.DeletePortMapping(ctx Context, protocol string, internalPort int) (err error) func github.com/libp2p/go-libp2p/p2p/net/reuseport.(*Transport).DialContext(ctx Context, raddr ma.Multiaddr) (manet.Conn, error) func github.com/libp2p/go-libp2p/p2p/net/swarm.(*Conn).NewStream(ctx Context) (network.Stream, error) func github.com/libp2p/go-libp2p/p2p/net/swarm.ResolverFromMaDNS.ResolveDNSAddr(ctx Context, expectedPeerID peer.ID, maddr ma.Multiaddr, recursionLimit int, outputLimit int) ([]ma.Multiaddr, error) func github.com/libp2p/go-libp2p/p2p/net/swarm.ResolverFromMaDNS.ResolveDNSComponent(ctx Context, maddr ma.Multiaddr, outputLimit int) ([]ma.Multiaddr, error) func github.com/libp2p/go-libp2p/p2p/net/swarm.(*Swarm).DialPeer(ctx Context, p peer.ID) (network.Conn, error) func github.com/libp2p/go-libp2p/p2p/net/swarm.(*Swarm).NewStream(ctx Context, p peer.ID) (network.Stream, error) func github.com/libp2p/go-libp2p/p2p/protocol/autonatv2.(*AutoNAT).GetReachability(ctx Context, reqs []autonatv2.Request) (autonatv2.Result, error) func github.com/libp2p/go-libp2p/p2p/protocol/circuitv2/client.Reserve(ctx Context, h host.Host, ai peer.AddrInfo) (*client.Reservation, error) func github.com/libp2p/go-libp2p/p2p/protocol/circuitv2/client.(*Client).Dial(ctx Context, a ma.Multiaddr, p peer.ID) (transport.CapableConn, error) func github.com/libp2p/go-libp2p/p2p/protocol/circuitv2/client.(*Client).SkipResolve(_ Context, _ ma.Multiaddr) bool func github.com/libp2p/go-libp2p/p2p/protocol/ping.Ping(ctx Context, h host.Host, p peer.ID) <-chan ping.Result func github.com/libp2p/go-libp2p/p2p/protocol/ping.(*PingService).Ping(ctx Context, p peer.ID) <-chan ping.Result func github.com/libp2p/go-libp2p/p2p/security/noise.EarlyDataHandler.Received(Context, net.Conn, *pb.NoiseExtensions) error func github.com/libp2p/go-libp2p/p2p/security/noise.EarlyDataHandler.Send(Context, net.Conn, peer.ID) *pb.NoiseExtensions func github.com/libp2p/go-libp2p/p2p/security/noise.(*SessionTransport).SecureInbound(ctx Context, insecure net.Conn, p peer.ID) (sec.SecureConn, error) func github.com/libp2p/go-libp2p/p2p/security/noise.(*SessionTransport).SecureOutbound(ctx Context, insecure net.Conn, p peer.ID) (sec.SecureConn, error) func github.com/libp2p/go-libp2p/p2p/security/noise.(*Transport).SecureInbound(ctx Context, insecure net.Conn, p peer.ID) (sec.SecureConn, error) func github.com/libp2p/go-libp2p/p2p/security/noise.(*Transport).SecureOutbound(ctx Context, insecure net.Conn, p peer.ID) (sec.SecureConn, error) func github.com/libp2p/go-libp2p/p2p/security/tls.(*Transport).SecureInbound(ctx Context, insecure net.Conn, p peer.ID) (sec.SecureConn, error) func github.com/libp2p/go-libp2p/p2p/security/tls.(*Transport).SecureOutbound(ctx Context, insecure net.Conn, p peer.ID) (sec.SecureConn, error) func github.com/libp2p/go-libp2p/p2p/transport/quicreuse.WithAssociation(ctx Context, association any) Context func github.com/libp2p/go-libp2p/p2p/transport/quicreuse.(*ConnManager).DialQUIC(ctx Context, raddr ma.Multiaddr, tlsConf *tls.Config, allowWindowIncrease func(conn quic.Connection, delta uint64) bool) (quic.Connection, error) func github.com/libp2p/go-libp2p/p2p/transport/quicreuse.Listener.Accept(Context) (quic.Connection, error) func github.com/libp2p/go-libp2p/p2p/transport/quicreuse.QUICListener.Accept(ctx Context) (quic.Connection, error) func github.com/libp2p/go-libp2p/p2p/transport/quicreuse.QUICTransport.Dial(ctx Context, addr net.Addr, tlsConf *tls.Config, conf *quic.Config) (quic.Connection, error) func github.com/libp2p/go-libp2p/p2p/transport/quicreuse.QUICTransport.ReadNonQUICPacket(ctx Context, b []byte) (int, net.Addr, error) func github.com/libp2p/go-libp2p/p2p/transport/quicreuse.RefCountedQUICTransport.Dial(ctx Context, addr net.Addr, tlsConf *tls.Config, conf *quic.Config) (quic.Connection, error) func github.com/libp2p/go-libp2p/p2p/transport/tcp.ContextDialer.DialContext(ctx Context, network, address string) (net.Conn, error) func github.com/libp2p/go-libp2p/p2p/transport/tcp.(*TcpTransport).Dial(ctx Context, raddr ma.Multiaddr, p peer.ID) (transport.CapableConn, error) func github.com/libp2p/go-libp2p/p2p/transport/tcp.(*TcpTransport).DialWithUpdates(ctx Context, raddr ma.Multiaddr, p peer.ID, updateChan chan<- transport.DialUpdate) (transport.CapableConn, error) func github.com/libp2p/go-libp2p/p2p/transport/tcpreuse.(*ConnMgr).DialContext(ctx Context, raddr ma.Multiaddr) (manet.Conn, error) func github.com/libp2p/go-libp2p/p2p/transport/webrtc.(*WebRTCTransport).Dial(ctx Context, remoteMultiaddr ma.Multiaddr, p peer.ID) (tpt.CapableConn, error) func github.com/libp2p/go-libp2p/p2p/transport/webrtc/udpmux.(*UDPMux).Accept(ctx Context) (udpmux.Candidate, error) func github.com/libp2p/go-libp2p/p2p/transport/websocket.(*WebsocketTransport).Dial(ctx Context, raddr ma.Multiaddr, p peer.ID) (transport.CapableConn, error) func github.com/libp2p/go-libp2p/p2p/transport/websocket.(*WebsocketTransport).Resolve(_ Context, maddr ma.Multiaddr) ([]ma.Multiaddr, error) func github.com/libp2p/go-libp2p-pubsub.NewFloodSub(ctx Context, h host.Host, opts ...pubsub.Option) (*pubsub.PubSub, error) func github.com/libp2p/go-libp2p-pubsub.NewFloodsubWithProtocols(ctx Context, h host.Host, ps []protocol.ID, opts ...pubsub.Option) (*pubsub.PubSub, error) func github.com/libp2p/go-libp2p-pubsub.NewGossipSub(ctx Context, h host.Host, opts ...pubsub.Option) (*pubsub.PubSub, error) func github.com/libp2p/go-libp2p-pubsub.NewGossipSubWithRouter(ctx Context, h host.Host, rt pubsub.PubSubRouter, opts ...pubsub.Option) (*pubsub.PubSub, error) func github.com/libp2p/go-libp2p-pubsub.NewPubSub(ctx Context, h host.Host, rt pubsub.PubSubRouter, opts ...pubsub.Option) (*pubsub.PubSub, error) func github.com/libp2p/go-libp2p-pubsub.NewRandomSub(ctx Context, h host.Host, size int, opts ...pubsub.Option) (*pubsub.PubSub, error) func github.com/libp2p/go-libp2p-pubsub.NewRemoteTracer(ctx Context, host host.Host, pi peer.AddrInfo) (*pubsub.RemoteTracer, error) func github.com/libp2p/go-libp2p-pubsub.PeerMetadataStore.Get(Context, peer.ID) ([]byte, error) func github.com/libp2p/go-libp2p-pubsub.PeerMetadataStore.Put(Context, peer.ID, []byte) error func github.com/libp2p/go-libp2p-pubsub.(*Subscription).Next(ctx Context) (*pubsub.Message, error) func github.com/libp2p/go-libp2p-pubsub.(*Topic).Publish(ctx Context, data []byte, opts ...pubsub.PubOpt) error func github.com/libp2p/go-libp2p-pubsub.(*TopicEventHandler).NextPeerEvent(ctx Context) (pubsub.PeerEvent, error) func github.com/libp2p/go-yamux/v5.(*Session).Open(ctx Context) (net.Conn, error) func github.com/libp2p/go-yamux/v5.(*Session).OpenStream(ctx Context) (*yamux.Stream, error) func github.com/miekg/dns.ExchangeContext(ctx Context, m *dns.Msg, a string) (r *dns.Msg, err error) func github.com/miekg/dns.(*Client).DialContext(ctx Context, address string) (conn *dns.Conn, err error) func github.com/miekg/dns.(*Client).ExchangeContext(ctx Context, m *dns.Msg, a string) (r *dns.Msg, rtt time.Duration, err error) func github.com/miekg/dns.(*Client).ExchangeWithConnContext(ctx Context, m *dns.Msg, co *dns.Conn) (r *dns.Msg, rtt time.Duration, err error) func github.com/miekg/dns.(*Server).ShutdownContext(ctx Context) error func github.com/modern-go/concurrent.(*UnboundedExecutor).StopAndWait(ctx Context) func github.com/multiformats/go-multiaddr/net.(*Dialer).DialContext(ctx Context, remote ma.Multiaddr) (manet.Conn, error) func github.com/multiformats/go-multiaddr-dns.Resolve(ctx Context, maddr ma.Multiaddr) ([]ma.Multiaddr, error) func github.com/multiformats/go-multiaddr-dns.BasicResolver.LookupIPAddr(Context, string) ([]net.IPAddr, error) func github.com/multiformats/go-multiaddr-dns.BasicResolver.LookupTXT(Context, string) ([]string, error) func github.com/multiformats/go-multiaddr-dns.(*MockResolver).LookupIPAddr(ctx Context, name string) ([]net.IPAddr, error) func github.com/multiformats/go-multiaddr-dns.(*MockResolver).LookupTXT(ctx Context, name string) ([]string, error) func github.com/multiformats/go-multiaddr-dns.(*Resolver).LookupIPAddr(ctx Context, domain string) ([]net.IPAddr, error) func github.com/multiformats/go-multiaddr-dns.(*Resolver).LookupTXT(ctx Context, txt string) ([]string, error) func github.com/multiformats/go-multiaddr-dns.(*Resolver).Resolve(ctx Context, maddr ma.Multiaddr) ([]ma.Multiaddr, error) func github.com/nats-io/nats.go.Context(ctx Context) nats.ContextOpt func github.com/nats-io/nats.go.(*Conn).FlushWithContext(ctx Context) error func github.com/nats-io/nats.go.(*Conn).RequestMsgWithContext(ctx Context, msg *nats.Msg) (*nats.Msg, error) func github.com/nats-io/nats.go.(*Conn).RequestWithContext(ctx Context, subj string, data []byte) (*nats.Msg, error) func github.com/nats-io/nats.go.(*EncodedConn).RequestWithContext(ctx Context, subject string, v any, vPtr any) error func github.com/nats-io/nats.go.(*Subscription).NextMsgWithContext(ctx Context) (*nats.Msg, error) func github.com/ncruces/go-sqlite3.OpenContext(ctx Context, filename string) (*sqlite3.Conn, error) func github.com/ncruces/go-sqlite3.(*Conn).SetInterrupt(ctx Context) (old Context) func github.com/ncruces/go-sqlite3/driver.Conn.BeginTx(ctx Context, opts driver.TxOptions) (driver.Tx, error) func github.com/ncruces/go-sqlite3/driver.Conn.PrepareContext(ctx Context, query string) (driver.Stmt, error) func github.com/ncruces/go-sqlite3/internal/util.AddHandle(ctx Context, a any) util.Ptr_t func github.com/ncruces/go-sqlite3/internal/util.DelHandle(ctx Context, id util.Ptr_t) error func github.com/ncruces/go-sqlite3/internal/util.GetHandle(ctx Context, id util.Ptr_t) any func github.com/ncruces/go-sqlite3/internal/util.MapRegion(ctx Context, mod api.Module, f *os.File, offset int64, size int32, readOnly bool) (*util.MappedRegion, error) func github.com/ncruces/go-sqlite3/internal/util.NewContext(ctx Context) Context func github.com/ncruces/go-sqlite3/vfs.GetFilename(ctx Context, mod api.Module, id vfs.ptr_t, flags vfs.OpenFlag) *vfs.Filename func github.com/pancsta/asyncmachine-go/examples/asynq_fileprocessing.HandleFileProcessingTask(ctx Context, t *asynq.Task) error func github.com/pancsta/asyncmachine-go/examples/benchmark_grpc.NewWorkerArpcServer(ctx Context, addr string, worker *benchmark_grpc.Worker) (*benchmark_grpc.WorkerArpcServer, error) func github.com/pancsta/asyncmachine-go/examples/benchmark_grpc.(*WorkerServiceServer).CallOp(ctx Context, req *pb.CallOpRequest) (*pb.CallOpResponse, error) func github.com/pancsta/asyncmachine-go/examples/benchmark_grpc.(*WorkerServiceServer).GetValue(ctx Context, req *pb.Empty) (*pb.GetValueResponse, error) func github.com/pancsta/asyncmachine-go/examples/benchmark_grpc.(*WorkerServiceServer).Start(ctx Context, req *pb.Empty) (*pb.Empty, error) func github.com/pancsta/asyncmachine-go/examples/benchmark_grpc/proto.UnimplementedWorkerServiceServer.CallOp(Context, *proto.CallOpRequest) (*proto.CallOpResponse, error) func github.com/pancsta/asyncmachine-go/examples/benchmark_grpc/proto.UnimplementedWorkerServiceServer.GetValue(Context, *proto.Empty) (*proto.GetValueResponse, error) func github.com/pancsta/asyncmachine-go/examples/benchmark_grpc/proto.UnimplementedWorkerServiceServer.Start(Context, *proto.Empty) (*proto.Empty, error) func github.com/pancsta/asyncmachine-go/examples/benchmark_grpc/proto.WorkerServiceClient.CallOp(ctx Context, in *proto.CallOpRequest, opts ...grpc.CallOption) (*proto.CallOpResponse, error) func github.com/pancsta/asyncmachine-go/examples/benchmark_grpc/proto.WorkerServiceClient.GetValue(ctx Context, in *proto.Empty, opts ...grpc.CallOption) (*proto.GetValueResponse, error) func github.com/pancsta/asyncmachine-go/examples/benchmark_grpc/proto.WorkerServiceClient.Start(ctx Context, in *proto.Empty, opts ...grpc.CallOption) (*proto.Empty, error) func github.com/pancsta/asyncmachine-go/examples/benchmark_grpc/proto.WorkerServiceClient.Subscribe(ctx Context, in *proto.Empty, opts ...grpc.CallOption) (grpc.ServerStreamingClient[proto.Empty], error) func github.com/pancsta/asyncmachine-go/examples/benchmark_grpc/proto.WorkerServiceServer.CallOp(Context, *proto.CallOpRequest) (*proto.CallOpResponse, error) func github.com/pancsta/asyncmachine-go/examples/benchmark_grpc/proto.WorkerServiceServer.GetValue(Context, *proto.Empty) (*proto.GetValueResponse, error) func github.com/pancsta/asyncmachine-go/examples/benchmark_grpc/proto.WorkerServiceServer.Start(Context, *proto.Empty) (*proto.Empty, error) func github.com/pancsta/asyncmachine-go/examples/benchmark_grpc/worker_proto.UnimplementedWorkerServiceServer.CallOp(Context, *worker_proto.CallOpRequest) (*worker_proto.CallOpResponse, error) func github.com/pancsta/asyncmachine-go/examples/benchmark_grpc/worker_proto.UnimplementedWorkerServiceServer.GetValue(Context, *worker_proto.Empty) (*worker_proto.GetValueResponse, error) func github.com/pancsta/asyncmachine-go/examples/benchmark_grpc/worker_proto.UnimplementedWorkerServiceServer.Start(Context, *worker_proto.Empty) (*worker_proto.Empty, error) func github.com/pancsta/asyncmachine-go/examples/benchmark_grpc/worker_proto.WorkerServiceClient.CallOp(ctx Context, in *worker_proto.CallOpRequest, opts ...grpc.CallOption) (*worker_proto.CallOpResponse, error) func github.com/pancsta/asyncmachine-go/examples/benchmark_grpc/worker_proto.WorkerServiceClient.GetValue(ctx Context, in *worker_proto.Empty, opts ...grpc.CallOption) (*worker_proto.GetValueResponse, error) func github.com/pancsta/asyncmachine-go/examples/benchmark_grpc/worker_proto.WorkerServiceClient.Start(ctx Context, in *worker_proto.Empty, opts ...grpc.CallOption) (*worker_proto.Empty, error) func github.com/pancsta/asyncmachine-go/examples/benchmark_grpc/worker_proto.WorkerServiceClient.Subscribe(ctx Context, in *worker_proto.Empty, opts ...grpc.CallOption) (grpc.ServerStreamingClient[worker_proto.Empty], error) func github.com/pancsta/asyncmachine-go/examples/benchmark_grpc/worker_proto.WorkerServiceServer.CallOp(Context, *worker_proto.CallOpRequest) (*worker_proto.CallOpResponse, error) func github.com/pancsta/asyncmachine-go/examples/benchmark_grpc/worker_proto.WorkerServiceServer.GetValue(Context, *worker_proto.Empty) (*worker_proto.GetValueResponse, error) func github.com/pancsta/asyncmachine-go/examples/benchmark_grpc/worker_proto.WorkerServiceServer.Start(Context, *worker_proto.Empty) (*worker_proto.Empty, error) func github.com/pancsta/asyncmachine-go/examples/mach_template.NewTemplate(ctx Context, num int) (*am.Machine, error) func github.com/pancsta/asyncmachine-go/examples/path_watcher.New(ctx Context) (*path_watcher.PathWatcher, error) func github.com/pancsta/asyncmachine-go/examples/temporal_fileprocessing.FileProcessingFlow(ctx Context, log temporal_fileprocessing.Logger, filename string) (*am.Machine, error) func github.com/pancsta/asyncmachine-go/examples/tree_state_source.ReadEnv(ctx Context) *main.Node func github.com/pancsta/asyncmachine-go/internal/testing.NewRpcClient(t *testing.T, ctx Context, addr string, stateStruct am.Schema, stateNames am.S, consumer *am.Machine) *rpc.Client func github.com/pancsta/asyncmachine-go/internal/testing.NewRpcTest(t *testing.T, ctx Context, worker *am.Machine, consumer *am.Machine) (*am.Machine, *rpc.Server, *rpc.Client) func github.com/pancsta/asyncmachine-go/internal/testing.RpcShutdown(ctx Context, c *rpc.Client, s *rpc.Server) func github.com/pancsta/asyncmachine-go/internal/testing/states.NewRel(ctx Context) *am.Machine func github.com/pancsta/asyncmachine-go/pkg/helpers.Add1Async(ctx Context, mach am.Api, waitState string, addState string, args am.A) am.Result func github.com/pancsta/asyncmachine-go/pkg/helpers.Add1Block(ctx Context, mach am.Api, state string, args am.A) am.Result func github.com/pancsta/asyncmachine-go/pkg/helpers.Add1Sync(ctx Context, mach am.Api, state string, args am.A) am.Result func github.com/pancsta/asyncmachine-go/pkg/helpers.EvalGetter[T](ctx Context, source string, maxTries int, mach *am.Machine, eval func() (T, error)) (T, error) func github.com/pancsta/asyncmachine-go/pkg/helpers.GroupWhen1(machs []am.Api, state string, ctx Context) ([]<-chan struct{}, error) func github.com/pancsta/asyncmachine-go/pkg/helpers.Interval(ctx Context, length time.Duration, interval time.Duration, fn func() bool) error func github.com/pancsta/asyncmachine-go/pkg/helpers.Wait(ctx Context, length time.Duration) bool func github.com/pancsta/asyncmachine-go/pkg/helpers.WaitForAll(ctx Context, timeout time.Duration, chans ...<-chan struct{}) error func github.com/pancsta/asyncmachine-go/pkg/helpers.WaitForAny(ctx Context, timeout time.Duration, chans ...<-chan struct{}) error func github.com/pancsta/asyncmachine-go/pkg/helpers.WaitForErrAll(ctx Context, timeout time.Duration, mach am.Api, chans ...<-chan struct{}) error func github.com/pancsta/asyncmachine-go/pkg/helpers.WaitForErrAny(ctx Context, timeout time.Duration, mach *am.Machine, chans ...<-chan struct{}) error func github.com/pancsta/asyncmachine-go/pkg/helpers.(*MutRequest).Run(ctx Context) (am.Result, error) func github.com/pancsta/asyncmachine-go/pkg/helpers.(*StateLoop).Ok(ctx Context) bool func github.com/pancsta/asyncmachine-go/pkg/helpers/testing.GroupWhen1(t *stdtest.T, mach []am.Api, state string, ctx Context) []<-chan struct{} func github.com/pancsta/asyncmachine-go/pkg/helpers/testing.Wait(t *stdtest.T, errMsg string, ctx Context, length time.Duration) func github.com/pancsta/asyncmachine-go/pkg/helpers/testing.WaitForAll(t *stdtest.T, source string, ctx Context, timeout time.Duration, chans ...<-chan struct{}) func github.com/pancsta/asyncmachine-go/pkg/helpers/testing.WaitForAny(t *stdtest.T, source string, ctx Context, timeout time.Duration, chans ...<-chan struct{}) func github.com/pancsta/asyncmachine-go/pkg/helpers/testing.WaitForErrAll(t *stdtest.T, source string, ctx Context, mach am.Api, timeout time.Duration, chans ...<-chan struct{}) func github.com/pancsta/asyncmachine-go/pkg/history.NewBaseMemory(ctx Context, mach am.Api, config history.BaseConfig, memImpl history.MemoryApi) *history.BaseMemory func github.com/pancsta/asyncmachine-go/pkg/history.NewMemory(ctx Context, machRecord *history.MachineRecord, mach am.Api, config history.BaseConfig, onErr func(err error)) (*history.Memory, error) func github.com/pancsta/asyncmachine-go/pkg/history.(*BaseMemory).ActivatedBetween(ctx Context, state string, start, end time.Time) bool func github.com/pancsta/asyncmachine-go/pkg/history.(*BaseMemory).ActiveBetween(ctx Context, state string, start, end time.Time) bool func github.com/pancsta/asyncmachine-go/pkg/history.(*BaseMemory).DeactivatedBetween(ctx Context, state string, start, end time.Time) bool func github.com/pancsta/asyncmachine-go/pkg/history.(*BaseMemory).FindLatest(ctx Context, retTx bool, limit int, query history.Query) ([]*history.MemoryRecord, error) func github.com/pancsta/asyncmachine-go/pkg/history.(*BaseMemory).InactiveBetween(ctx Context, state string, start, end time.Time) bool func github.com/pancsta/asyncmachine-go/pkg/history.(*Memory).FindLatest(ctx Context, _ bool, limit int, query history.Query) ([]*history.MemoryRecord, error) func github.com/pancsta/asyncmachine-go/pkg/history.(*Memory).Match(ctx Context, matcherFn history.MatcherFn) ([]*history.MemoryRecord, error) func github.com/pancsta/asyncmachine-go/pkg/history.MemoryApi.ActivatedBetween(ctx Context, state string, start, end time.Time) bool func github.com/pancsta/asyncmachine-go/pkg/history.MemoryApi.ActiveBetween(ctx Context, state string, start, end time.Time) bool func github.com/pancsta/asyncmachine-go/pkg/history.MemoryApi.DeactivatedBetween(ctx Context, state string, start, end time.Time) bool func github.com/pancsta/asyncmachine-go/pkg/history.MemoryApi.FindLatest(ctx Context, retTx bool, limit int, query history.Query) ([]*history.MemoryRecord, error) func github.com/pancsta/asyncmachine-go/pkg/history.MemoryApi.InactiveBetween(ctx Context, state string, start, end time.Time) bool func github.com/pancsta/asyncmachine-go/pkg/history/bbolt.NewMemory(ctx Context, db *bbolt.DB, mach am.Api, cfg bbolt.Config, onErr func(err error)) (*bbolt.Memory, error) func github.com/pancsta/asyncmachine-go/pkg/history/bbolt.(*Memory).FindLatest(ctx Context, retTx bool, limit int, query amhist.Query) ([]*amhist.MemoryRecord, error) func github.com/pancsta/asyncmachine-go/pkg/history/bbolt.(*Memory).Match(ctx Context, matcherFn bbolt.MatcherFn) ([]*amhist.MemoryRecord, error) func github.com/pancsta/asyncmachine-go/pkg/history/gorm.NewMemory(ctx Context, db *gorm.DB, mach am.Api, cfg gorm.Config, onErr func(err error)) (*gorm.Memory, error) func github.com/pancsta/asyncmachine-go/pkg/history/gorm.(*Memory).FindLatest(ctx Context, retTx bool, limit int, query amhist.Query) ([]*amhist.MemoryRecord, error) func github.com/pancsta/asyncmachine-go/pkg/history/gorm.(*Memory).Match(ctx Context, limit int, matcherFn gorm.MatcherFn) ([]*amhist.MemoryRecord, error) func github.com/pancsta/asyncmachine-go/pkg/integrations.HandlerGetter(ctx Context, mach am.Api, req *integrations.GetterReq) (*integrations.GetterResp, error) func github.com/pancsta/asyncmachine-go/pkg/integrations.HandlerMutation(ctx Context, mach am.Api, req *integrations.MutationReq) (*integrations.MutationResp, error) func github.com/pancsta/asyncmachine-go/pkg/integrations.HandlerWaiting(ctx Context, mach am.Api, req *integrations.WaitingReq) (*integrations.WaitingResp, error) func github.com/pancsta/asyncmachine-go/pkg/integrations/nats.Add(ctx Context, nc *nats.Conn, topic, machID string, states am.S, args am.A) (am.Result, error) func github.com/pancsta/asyncmachine-go/pkg/integrations/nats.ExposeMachine(ctx Context, mach am.Api, nc *nats.Conn, topic, queue string) error func github.com/pancsta/asyncmachine-go/pkg/integrations/nats.Remove(ctx Context, nc *nats.Conn, machID, topic string, states am.S, args am.A) (am.Result, error) func github.com/pancsta/asyncmachine-go/pkg/machine.New(ctx Context, schema machine.Schema, opts *machine.Opts) *machine.Machine func github.com/pancsta/asyncmachine-go/pkg/machine.NewCommon(ctx Context, id string, stateSchema machine.Schema, stateNames machine.S, handlers any, parent machine.Api, opts *machine.Opts) (*machine.Machine, error) func github.com/pancsta/asyncmachine-go/pkg/machine.Api.When(states machine.S, ctx Context) <-chan struct{} func github.com/pancsta/asyncmachine-go/pkg/machine.Api.When1(state string, ctx Context) <-chan struct{} func github.com/pancsta/asyncmachine-go/pkg/machine.Api.WhenArgs(state string, args machine.A, ctx Context) <-chan struct{} func github.com/pancsta/asyncmachine-go/pkg/machine.Api.WhenErr(ctx Context) <-chan struct{} func github.com/pancsta/asyncmachine-go/pkg/machine.Api.WhenNot(states machine.S, ctx Context) <-chan struct{} func github.com/pancsta/asyncmachine-go/pkg/machine.Api.WhenNot1(state string, ctx Context) <-chan struct{} func github.com/pancsta/asyncmachine-go/pkg/machine.Api.WhenQuery(query func(clock machine.Clock) bool, ctx Context) <-chan struct{} func github.com/pancsta/asyncmachine-go/pkg/machine.Api.WhenTicks(state string, ticks int, ctx Context) <-chan struct{} func github.com/pancsta/asyncmachine-go/pkg/machine.Api.WhenTime(states machine.S, times machine.Time, ctx Context) <-chan struct{} func github.com/pancsta/asyncmachine-go/pkg/machine.Api.WhenTime1(state string, tick uint64, ctx Context) <-chan struct{} func github.com/pancsta/asyncmachine-go/pkg/machine.(*Machine).Eval(source string, fn func(), ctx Context) bool func github.com/pancsta/asyncmachine-go/pkg/machine.(*Machine).When(states machine.S, ctx Context) <-chan struct{} func github.com/pancsta/asyncmachine-go/pkg/machine.(*Machine).When1(state string, ctx Context) <-chan struct{} func github.com/pancsta/asyncmachine-go/pkg/machine.(*Machine).WhenArgs(state string, args machine.A, ctx Context) <-chan struct{} func github.com/pancsta/asyncmachine-go/pkg/machine.(*Machine).WhenErr(disposeCtx Context) <-chan struct{} func github.com/pancsta/asyncmachine-go/pkg/machine.(*Machine).WhenNot(states machine.S, ctx Context) <-chan struct{} func github.com/pancsta/asyncmachine-go/pkg/machine.(*Machine).WhenNot1(state string, ctx Context) <-chan struct{} func github.com/pancsta/asyncmachine-go/pkg/machine.(*Machine).WhenQuery(clockCheck func(clock machine.Clock) bool, ctx Context) <-chan struct{} func github.com/pancsta/asyncmachine-go/pkg/machine.(*Machine).WhenQueueEnds(ctx Context) <-chan struct{} func github.com/pancsta/asyncmachine-go/pkg/machine.(*Machine).WhenTicks(state string, ticks int, ctx Context) <-chan struct{} func github.com/pancsta/asyncmachine-go/pkg/machine.(*Machine).WhenTime(states machine.S, times machine.Time, ctx Context) <-chan struct{} func github.com/pancsta/asyncmachine-go/pkg/machine.(*Machine).WhenTime1(state string, ticks uint64, ctx Context) <-chan struct{} func github.com/pancsta/asyncmachine-go/pkg/machine.(*Subscriptions).When(states machine.S, ctx Context) <-chan struct{} func github.com/pancsta/asyncmachine-go/pkg/machine.(*Subscriptions).WhenArgs(state string, args machine.A, ctx Context) <-chan struct{} func github.com/pancsta/asyncmachine-go/pkg/machine.(*Subscriptions).WhenNot(states machine.S, ctx Context) <-chan struct{} func github.com/pancsta/asyncmachine-go/pkg/machine.(*Subscriptions).WhenQuery(fn func(clock machine.Clock) bool, ctx Context) <-chan struct{} func github.com/pancsta/asyncmachine-go/pkg/machine.(*Subscriptions).WhenQueueEnds(ctx Context, mx *sync.RWMutex) <-chan struct{} func github.com/pancsta/asyncmachine-go/pkg/machine.(*Subscriptions).WhenTime(states machine.S, times machine.Time, ctx Context) <-chan struct{} func github.com/pancsta/asyncmachine-go/pkg/node.NewClient(ctx Context, id string, workerKind string, stateDeps *node.ClientStateDeps, opts *node.ClientOpts) (*node.Client, error) func github.com/pancsta/asyncmachine-go/pkg/node.NewSupervisor(ctx Context, workerKind string, workerBin []string, workerStruct am.Schema, workerSNames am.S, opts *node.SupervisorOpts) (*node.Supervisor, error) func github.com/pancsta/asyncmachine-go/pkg/node.NewWorker(ctx Context, kind string, workerStruct am.Schema, stateNames am.S, opts *node.WorkerOpts) (*node.Worker, error) func github.com/pancsta/asyncmachine-go/pkg/node.(*Client).Dispose(ctx Context) func github.com/pancsta/asyncmachine-go/pkg/node.(*Client).ReqWorker(ctx Context) error func github.com/pancsta/asyncmachine-go/pkg/node.(*Client).Stop(ctx Context) func github.com/pancsta/asyncmachine-go/pkg/node.(*Supervisor).Workers(ctx Context, state node.WorkerState) ([]*node.workerInfo, error) func github.com/pancsta/asyncmachine-go/pkg/pubsub.NewTopic(ctx Context, name, suffix string, exposedMachs []*am.Machine, opts *pubsub.TopicOpts) (*pubsub.Topic, error) func github.com/pancsta/asyncmachine-go/pkg/pubsub.(*Topic).StartAndJoin(ctx Context) am.Result func github.com/pancsta/asyncmachine-go/pkg/pubsub/uds.(*UdsTransport).Dial(ctx Context, raddr ma.Multiaddr, p peer.ID) (transport.CapableConn, error) func github.com/pancsta/asyncmachine-go/pkg/pubsub/uds.(*UdsTransport).DialWithUpdates(ctx Context, raddr ma.Multiaddr, p peer.ID, updateChan chan<- transport.DialUpdate) (transport.CapableConn, error) func github.com/pancsta/asyncmachine-go/pkg/rpc.NewClient(ctx Context, workerAddr string, name string, stateStruct am.Schema, stateNames am.S, opts *rpc.ClientOpts) (*rpc.Client, error) func github.com/pancsta/asyncmachine-go/pkg/rpc.NewMux(ctx Context, name string, newServerFn rpc.MuxNewServerFn, opts *rpc.MuxOpts) (*rpc.Mux, error) func github.com/pancsta/asyncmachine-go/pkg/rpc.NewServer(ctx Context, addr string, name string, sourceMach am.Api, opts *rpc.ServerOpts) (*rpc.Server, error) func github.com/pancsta/asyncmachine-go/pkg/rpc.NewWorker(ctx Context, id string, c *rpc.Client, schema am.Schema, stateNames am.S, parent *am.Machine, tags []string) (*rpc.Worker, error) func github.com/pancsta/asyncmachine-go/pkg/rpc.(*Client).Stop(waitTillExit Context, dispose bool) am.Result func github.com/pancsta/asyncmachine-go/pkg/rpc.(*Server).SendPayload(ctx Context, event *am.Event, payload *rpc.ArgsPayload) error func github.com/pancsta/asyncmachine-go/pkg/rpc.(*Worker).When(states am.S, ctx Context) <-chan struct{} func github.com/pancsta/asyncmachine-go/pkg/rpc.(*Worker).When1(state string, ctx Context) <-chan struct{} func github.com/pancsta/asyncmachine-go/pkg/rpc.(*Worker).WhenArgs(state string, args am.A, ctx Context) <-chan struct{} func github.com/pancsta/asyncmachine-go/pkg/rpc.(*Worker).WhenErr(disposeCtx Context) <-chan struct{} func github.com/pancsta/asyncmachine-go/pkg/rpc.(*Worker).WhenNot(states am.S, ctx Context) <-chan struct{} func github.com/pancsta/asyncmachine-go/pkg/rpc.(*Worker).WhenNot1(state string, ctx Context) <-chan struct{} func github.com/pancsta/asyncmachine-go/pkg/rpc.(*Worker).WhenQuery(clockCheck func(clock am.Clock) bool, ctx Context) <-chan struct{} func github.com/pancsta/asyncmachine-go/pkg/rpc.(*Worker).WhenTicks(state string, ticks int, ctx Context) <-chan struct{} func github.com/pancsta/asyncmachine-go/pkg/rpc.(*Worker).WhenTime(states am.S, times am.Time, ctx Context) <-chan struct{} func github.com/pancsta/asyncmachine-go/pkg/rpc.(*Worker).WhenTime1(state string, ticks uint64, ctx Context) <-chan struct{} func github.com/pancsta/asyncmachine-go/pkg/telemetry.NewOtelProvider(source string, ctx Context) (trace.Tracer, *sdktrace.TracerProvider, error) func github.com/pancsta/asyncmachine-go/pkg/x/helpers.ErrFromCtxs(ctxs ...Context) error func github.com/pancsta/asyncmachine-go/pkg/x/helpers.RaceCtx[T](ctx Context, ch chan T) (T, error) func github.com/pancsta/asyncmachine-go/pkg/x/history/frostdb.NewMemory(ctx Context) (*frostdb.Memory, error) func github.com/pancsta/asyncmachine-go/tools/debugger.New(ctx Context, opts debugger.Opts) (*debugger.Debugger, error) func github.com/pancsta/asyncmachine-go/tools/debugger/types.StartCpuProfileSrv(ctx Context, logger *log.Logger, p *types.Params) func github.com/pancsta/asyncmachine-go/tools/generator.NewSchemaGenerator(ctx Context, param cli.SFParams) (*generator.SchemaGenerator, error) func github.com/pancsta/asyncmachine-go/tools/generator.SyncDashboard(ctx Context, p cli.GrafanaParams, builder *dashboard.Builder) error func github.com/pancsta/asyncmachine-go/tools/relay.New(ctx Context, args *types.Args, out types.OutputFunc) (*relay.Relay, error) func github.com/pancsta/asyncmachine-go/tools/repl.New(ctx Context, id string) (*repl.Repl, error) func github.com/pancsta/asyncmachine-go/tools/visualizer.New(ctx Context, name string) (*visualizer.Visualizer, error) func github.com/pancsta/asyncmachine-go/tools/visualizer.UpdateCache(ctx Context, filepath string, dom *goquery.Document, fragments ...*visualizer.Fragment) error func github.com/pancsta/asyncmachine-go/tools/visualizer.(*Renderer).GenDiagrams(ctx Context) error func github.com/pancsta/asyncmachine-go/tools/visualizer/types.StartCpuProfileSrv(ctx Context, logger *log.Logger, p *types.Params) func github.com/pion/dtls/v2.ClientWithContext(ctx Context, conn net.Conn, config *dtls.Config) (*dtls.Conn, error) func github.com/pion/dtls/v2.DialWithContext(ctx Context, network string, raddr *net.UDPAddr, config *dtls.Config) (*dtls.Conn, error) func github.com/pion/dtls/v2.ServerWithContext(ctx Context, conn net.Conn, config *dtls.Config) (*dtls.Conn, error) func github.com/pion/dtls/v2/internal/closer.NewCloserWithParent(ctx Context) *closer.Closer func github.com/pion/dtls/v3.(*Conn).HandshakeContext(ctx Context) error func github.com/pion/dtls/v3/internal/closer.NewCloserWithParent(ctx Context) *closer.Closer func github.com/pion/ice/v4.(*Agent).Accept(ctx Context, remoteUfrag, remotePwd string) (*ice.Conn, error) func github.com/pion/ice/v4.(*Agent).Dial(ctx Context, remoteUfrag, remotePwd string) (*ice.Conn, error) func github.com/pion/ice/v4/internal/taskloop.(*Loop).Run(ctx Context, t func(Context)) error func github.com/pion/mdns/v2.(*Conn).Query(ctx Context, name string) (dnsmessage.ResourceHeader, net.Addr, error) func github.com/pion/mdns/v2.(*Conn).QueryAddr(ctx Context, name string) (dnsmessage.ResourceHeader, netip.Addr, error) func github.com/pion/sctp.(*Association).Shutdown(ctx Context) error func github.com/pion/transport/v2/connctx.ConnCtx.ReadContext(Context, []byte) (int, error) func github.com/pion/transport/v2/connctx.ConnCtx.WriteContext(Context, []byte) (int, error) func github.com/pion/transport/v2/connctx.Reader.ReadContext(Context, []byte) (int, error) func github.com/pion/transport/v2/connctx.ReadWriter.ReadContext(Context, []byte) (int, error) func github.com/pion/transport/v2/connctx.ReadWriter.WriteContext(Context, []byte) (int, error) func github.com/pion/transport/v2/connctx.Writer.WriteContext(Context, []byte) (int, error) func github.com/pion/transport/v3/netctx.Conn.ReadContext(Context, []byte) (int, error) func github.com/pion/transport/v3/netctx.Conn.WriteContext(Context, []byte) (int, error) func github.com/pion/transport/v3/netctx.PacketConn.ReadFromContext(Context, []byte) (int, net.Addr, error) func github.com/pion/transport/v3/netctx.PacketConn.WriteToContext(Context, []byte, net.Addr) (int, error) func github.com/pion/transport/v3/netctx.Reader.ReadContext(Context, []byte) (int, error) func github.com/pion/transport/v3/netctx.ReaderFrom.ReadFromContext(Context, []byte) (int, net.Addr, error) func github.com/pion/transport/v3/netctx.ReadWriter.ReadContext(Context, []byte) (int, error) func github.com/pion/transport/v3/netctx.ReadWriter.WriteContext(Context, []byte) (int, error) func github.com/pion/transport/v3/netctx.Writer.WriteContext(Context, []byte) (int, error) func github.com/pion/transport/v3/netctx.WriterTo.WriteToContext(Context, []byte, net.Addr) (int, error) func github.com/pion/transport/v3/vnet.(*DelayFilter).Run(ctx Context) func github.com/polarsignals/frostdb.LoadSnapshot(ctx Context, db *frostdb.DB, tx uint64, r io.ReaderAt, size int64, dir string, truncateWAL bool) (uint64, error) func github.com/polarsignals/frostdb.StoreSnapshot(ctx Context, tx uint64, db *frostdb.DB, snapshot io.Reader) error func github.com/polarsignals/frostdb.WriteSnapshot(ctx Context, tx uint64, db *frostdb.DB, w io.Writer) error func github.com/polarsignals/frostdb.(*ColumnStore).DB(ctx Context, name string, opts ...frostdb.DBOption) (*frostdb.DB, error) func github.com/polarsignals/frostdb.DataSink.Delete(ctx Context, name string) error func github.com/polarsignals/frostdb.DataSink.Upload(ctx Context, name string, r io.Reader) error func github.com/polarsignals/frostdb.DataSinkSource.Delete(ctx Context, name string) error func github.com/polarsignals/frostdb.DataSinkSource.Prefixes(ctx Context, prefix string) ([]string, error) func github.com/polarsignals/frostdb.DataSinkSource.Scan(ctx Context, prefix string, schema *dynparquet.Schema, filter logicalplan.Expr, lastBlockTimestamp uint64, callback func(Context, any) error) error func github.com/polarsignals/frostdb.DataSinkSource.Upload(ctx Context, name string, r io.Reader) error func github.com/polarsignals/frostdb.DataSource.Prefixes(ctx Context, prefix string) ([]string, error) func github.com/polarsignals/frostdb.DataSource.Scan(ctx Context, prefix string, schema *dynparquet.Schema, filter logicalplan.Expr, lastBlockTimestamp uint64, callback func(Context, any) error) error func github.com/polarsignals/frostdb.(*DB).Snapshot(ctx Context) error func github.com/polarsignals/frostdb.(*DefaultObjstoreBucket).Prefixes(ctx Context, prefix string) ([]string, error) func github.com/polarsignals/frostdb.(*DefaultObjstoreBucket).ProcessFile(ctx Context, blockDir string, lastBlockTimestamp uint64, filter expr.TrueNegativeFilter, callback func(Context, any) error) error func github.com/polarsignals/frostdb.(*DefaultObjstoreBucket).Scan(ctx Context, prefix string, _ *dynparquet.Schema, filter logicalplan.Expr, lastBlockTimestamp uint64, callback func(Context, any) error) error func github.com/polarsignals/frostdb.(*GenericTable)[T].Write(ctx Context, values ...T) (uint64, error) func github.com/polarsignals/frostdb.(*Table).InsertRecord(ctx Context, record arrow.Record) (uint64, error) func github.com/polarsignals/frostdb.(*Table).Iterator(ctx Context, tx uint64, pool memory.Allocator, callbacks []logicalplan.Callback, options ...logicalplan.Option) error func github.com/polarsignals/frostdb.(*Table).RotateBlock(_ Context, block *frostdb.TableBlock, opts ...frostdb.RotateBlockOption) error func github.com/polarsignals/frostdb.(*Table).SchemaIterator(ctx Context, tx uint64, pool memory.Allocator, callbacks []logicalplan.Callback, options ...logicalplan.Option) error func github.com/polarsignals/frostdb.(*Table).View(ctx Context, fn func(ctx Context, tx uint64) error) error func github.com/polarsignals/frostdb.(*TableBlock).InsertRecord(_ Context, tx uint64, record arrow.Record) error func github.com/polarsignals/frostdb/index.(*LSM).Prefixes(_ Context, _ string) ([]string, error) func github.com/polarsignals/frostdb/index.(*LSM).Scan(ctx Context, _ string, _ *dynparquet.Schema, filter logicalplan.Expr, tx uint64, callback func(Context, any) error) error func github.com/polarsignals/frostdb/pqarrow.ParquetRowGroupToArrowSchema(ctx Context, rg parquet.RowGroup, s *dynparquet.Schema, options logicalplan.IterOptions) (*arrow.Schema, error) func github.com/polarsignals/frostdb/pqarrow.ParquetSchemaToArrowSchema(ctx Context, schema *parquet.Schema, s *dynparquet.Schema, options logicalplan.IterOptions) (*arrow.Schema, error) func github.com/polarsignals/frostdb/pqarrow.(*ParquetConverter).Convert(ctx Context, rg parquet.RowGroup, s *dynparquet.Schema) error func github.com/polarsignals/frostdb/pqarrow/arrowutils.Take(ctx Context, r arrow.Record, indices *array.Int32) (arrow.Record, error) func github.com/polarsignals/frostdb/pqarrow/arrowutils.TakeColumn(ctx Context, a arrow.Array, idx int, arr []arrow.Array, indices *array.Int32) error func github.com/polarsignals/frostdb/pqarrow/arrowutils.TakeDictColumn(ctx Context, a *array.Dictionary, idx int, arr []arrow.Array, indices *array.Int32) error func github.com/polarsignals/frostdb/pqarrow/arrowutils.TakeListColumn(ctx Context, a *array.List, idx int, arr []arrow.Array, indices *array.Int32) error func github.com/polarsignals/frostdb/pqarrow/arrowutils.TakeRunEndEncodedColumn(ctx Context, a *array.RunEndEncoded, idx int, arr []arrow.Array, indices *array.Int32) error func github.com/polarsignals/frostdb/pqarrow/arrowutils.TakeStructColumn(ctx Context, a *array.Struct, idx int, arr []arrow.Array, indices *array.Int32) error func github.com/polarsignals/frostdb/query/logicalplan.TableReader.Iterator(ctx Context, tx uint64, pool memory.Allocator, callbacks []logicalplan.Callback, options ...logicalplan.Option) error func github.com/polarsignals/frostdb/query/logicalplan.TableReader.SchemaIterator(ctx Context, tx uint64, pool memory.Allocator, callbacks []logicalplan.Callback, options ...logicalplan.Option) error func github.com/polarsignals/frostdb/query/logicalplan.TableReader.View(ctx Context, fn func(ctx Context, tx uint64) error) error func github.com/polarsignals/frostdb/query/physicalplan.Build(ctx Context, pool memory.Allocator, tracer trace.Tracer, s *dynparquet.Schema, plan *logicalplan.LogicalPlan, options ...physicalplan.Option) (*physicalplan.OutputPlan, error) func github.com/polarsignals/frostdb/query/physicalplan.(*Distinction).Callback(ctx Context, r arrow.Record) error func github.com/polarsignals/frostdb/query/physicalplan.(*Distinction).Finish(ctx Context) error func github.com/polarsignals/frostdb/query/physicalplan.(*HashAggregate).Callback(_ Context, r arrow.Record) error func github.com/polarsignals/frostdb/query/physicalplan.(*HashAggregate).Finish(ctx Context) error func github.com/polarsignals/frostdb/query/physicalplan.(*Limiter).Callback(ctx Context, r arrow.Record) error func github.com/polarsignals/frostdb/query/physicalplan.(*Limiter).Finish(ctx Context) error func github.com/polarsignals/frostdb/query/physicalplan.(*OrderedAggregate).Callback(_ Context, r arrow.Record) error func github.com/polarsignals/frostdb/query/physicalplan.(*OrderedAggregate).Finish(ctx Context) error func github.com/polarsignals/frostdb/query/physicalplan.(*OrderedSynchronizer).Callback(ctx Context, r arrow.Record) error func github.com/polarsignals/frostdb/query/physicalplan.(*OrderedSynchronizer).Finish(ctx Context) error func github.com/polarsignals/frostdb/query/physicalplan.(*OutputPlan).Callback(ctx Context, r arrow.Record) error func github.com/polarsignals/frostdb/query/physicalplan.(*OutputPlan).Execute(ctx Context, pool memory.Allocator, callback func(ctx Context, r arrow.Record) error) error func github.com/polarsignals/frostdb/query/physicalplan.(*OutputPlan).Finish(_ Context) error func github.com/polarsignals/frostdb/query/physicalplan.PhysicalPlan.Callback(ctx Context, r arrow.Record) error func github.com/polarsignals/frostdb/query/physicalplan.PhysicalPlan.Finish(ctx Context) error func github.com/polarsignals/frostdb/query/physicalplan.(*PredicateFilter).Callback(ctx Context, r arrow.Record) error func github.com/polarsignals/frostdb/query/physicalplan.(*PredicateFilter).Finish(ctx Context) error func github.com/polarsignals/frostdb/query/physicalplan.(*Projection).Callback(ctx Context, r arrow.Record) error func github.com/polarsignals/frostdb/query/physicalplan.(*Projection).Finish(ctx Context) error func github.com/polarsignals/frostdb/query/physicalplan.(*Projection).Project(_ Context, r arrow.Record) (arrow.Record, error) func github.com/polarsignals/frostdb/query/physicalplan.(*ReservoirSampler).Callback(_ Context, r arrow.Record) error func github.com/polarsignals/frostdb/query/physicalplan.(*ReservoirSampler).Finish(ctx Context) error func github.com/polarsignals/frostdb/query/physicalplan.ScanPhysicalPlan.Execute(ctx Context, pool memory.Allocator) error func github.com/polarsignals/frostdb/query/physicalplan.(*SchemaScan).Execute(ctx Context, pool memory.Allocator) error func github.com/polarsignals/frostdb/query/physicalplan.(*Synchronizer).Callback(ctx Context, r arrow.Record) error func github.com/polarsignals/frostdb/query/physicalplan.(*Synchronizer).Finish(ctx Context) error func github.com/polarsignals/frostdb/query/physicalplan.(*TableScan).Execute(ctx Context, pool memory.Allocator) error func github.com/polarsignals/frostdb/storage.Bucket.Attributes(ctx Context, name string) (objstore.ObjectAttributes, error) func github.com/polarsignals/frostdb/storage.Bucket.Delete(ctx Context, name string) error func github.com/polarsignals/frostdb/storage.Bucket.Exists(ctx Context, name string) (bool, error) func github.com/polarsignals/frostdb/storage.Bucket.Get(ctx Context, name string) (io.ReadCloser, error) func github.com/polarsignals/frostdb/storage.Bucket.GetRange(ctx Context, name string, off, length int64) (io.ReadCloser, error) func github.com/polarsignals/frostdb/storage.Bucket.GetReaderAt(ctx Context, name string) (io.ReaderAt, error) func github.com/polarsignals/frostdb/storage.Bucket.Iter(ctx Context, dir string, f func(string) error, options ...objstore.IterOption) error func github.com/polarsignals/frostdb/storage.Bucket.Upload(ctx Context, name string, r io.Reader) error func github.com/polarsignals/frostdb/storage.(*BucketReaderAt).GetReaderAt(ctx Context, name string) (io.ReaderAt, error) func github.com/polarsignals/frostdb/storage.(*Iceberg).Delete(_ Context, _ string) error func github.com/polarsignals/frostdb/storage.(*Iceberg).Maintenance(ctx Context) error func github.com/polarsignals/frostdb/storage.(*Iceberg).Prefixes(ctx Context, prefix string) ([]string, error) func github.com/polarsignals/frostdb/storage.(*Iceberg).Scan(ctx Context, prefix string, _ *dynparquet.Schema, filter logicalplan.Expr, _ uint64, callback func(Context, any) error) error func github.com/polarsignals/frostdb/storage.(*Iceberg).Upload(ctx Context, name string, r io.Reader) error func github.com/polarsignals/iceberg-go/catalog.Catalog.CreateNamespace(ctx Context, namespace table.Identifier, props iceberg.Properties) error func github.com/polarsignals/iceberg-go/catalog.Catalog.CreateTable(ctx Context, location string, schema *iceberg.Schema, props iceberg.Properties, options ...catalog.TableOption) (table.Table, error) func github.com/polarsignals/iceberg-go/catalog.Catalog.DropNamespace(ctx Context, namespace table.Identifier) error func github.com/polarsignals/iceberg-go/catalog.Catalog.DropTable(ctx Context, identifier table.Identifier) error func github.com/polarsignals/iceberg-go/catalog.Catalog.ListNamespaces(ctx Context, parent table.Identifier) ([]table.Identifier, error) func github.com/polarsignals/iceberg-go/catalog.Catalog.ListTables(ctx Context, namespace table.Identifier) ([]table.Identifier, error) func github.com/polarsignals/iceberg-go/catalog.Catalog.LoadNamespaceProperties(ctx Context, namespace table.Identifier) (iceberg.Properties, error) func github.com/polarsignals/iceberg-go/catalog.Catalog.LoadTable(ctx Context, identifier table.Identifier, props iceberg.Properties) (table.Table, error) func github.com/polarsignals/iceberg-go/catalog.Catalog.RenameTable(ctx Context, from, to table.Identifier) (table.Table, error) func github.com/polarsignals/iceberg-go/catalog.Catalog.UpdateNamespaceProperties(ctx Context, namespace table.Identifier, removals []string, updates iceberg.Properties) (catalog.PropertiesUpdateSummary, error) func github.com/polarsignals/iceberg-go/table.DeleteOrphanFiles(ctx Context, table table.Table, age time.Duration) error func github.com/polarsignals/iceberg-go/table.SnapshotWriter.Append(ctx Context, r io.Reader) error func github.com/polarsignals/iceberg-go/table.SnapshotWriter.Close(ctx Context) error func github.com/polarsignals/iceberg-go/table.SnapshotWriter.DeleteDataFile(ctx Context, del func(file iceberg.DataFile) bool) error func github.com/prometheus/client_golang/prometheus/push.(*Pusher).AddContext(ctx Context) error func github.com/prometheus/client_golang/prometheus/push.(*Pusher).PushContext(ctx Context) error func github.com/quic-go/quic-go.Dial(ctx Context, c net.PacketConn, addr net.Addr, tlsConf *tls.Config, conf *quic.Config) (quic.Connection, error) func github.com/quic-go/quic-go.DialAddr(ctx Context, addr string, tlsConf *tls.Config, conf *quic.Config) (quic.Connection, error) func github.com/quic-go/quic-go.DialAddrEarly(ctx Context, addr string, tlsConf *tls.Config, conf *quic.Config) (quic.EarlyConnection, error) func github.com/quic-go/quic-go.DialEarly(ctx Context, c net.PacketConn, addr net.Addr, tlsConf *tls.Config, conf *quic.Config) (quic.EarlyConnection, error) func github.com/quic-go/quic-go.Connection.AcceptStream(Context) (quic.Stream, error) func github.com/quic-go/quic-go.Connection.AcceptUniStream(Context) (quic.ReceiveStream, error) func github.com/quic-go/quic-go.Connection.OpenStreamSync(Context) (quic.Stream, error) func github.com/quic-go/quic-go.Connection.OpenUniStreamSync(Context) (quic.SendStream, error) func github.com/quic-go/quic-go.Connection.ReceiveDatagram(Context) ([]byte, error) func github.com/quic-go/quic-go.EarlyConnection.AcceptStream(Context) (quic.Stream, error) func github.com/quic-go/quic-go.EarlyConnection.AcceptUniStream(Context) (quic.ReceiveStream, error) func github.com/quic-go/quic-go.EarlyConnection.NextConnection(Context) (quic.Connection, error) func github.com/quic-go/quic-go.EarlyConnection.OpenStreamSync(Context) (quic.Stream, error) func github.com/quic-go/quic-go.EarlyConnection.OpenUniStreamSync(Context) (quic.SendStream, error) func github.com/quic-go/quic-go.EarlyConnection.ReceiveDatagram(Context) ([]byte, error) func github.com/quic-go/quic-go.(*EarlyListener).Accept(ctx Context) (quic.EarlyConnection, error) func github.com/quic-go/quic-go.(*Listener).Accept(ctx Context) (quic.Connection, error) func github.com/quic-go/quic-go.(*Path).Probe(ctx Context) error func github.com/quic-go/quic-go.(*Transport).Dial(ctx Context, addr net.Addr, tlsConf *tls.Config, conf *quic.Config) (quic.Connection, error) func github.com/quic-go/quic-go.(*Transport).DialEarly(ctx Context, addr net.Addr, tlsConf *tls.Config, conf *quic.Config) (quic.EarlyConnection, error) func github.com/quic-go/quic-go.(*Transport).ReadNonQUICPacket(ctx Context, b []byte) (int, net.Addr, error) func github.com/quic-go/quic-go/http3.(*ClientConn).OpenRequestStream(ctx Context) (http3.RequestStream, error) func github.com/quic-go/quic-go/http3.Connection.OpenStreamSync(Context) (quic.Stream, error) func github.com/quic-go/quic-go/http3.Connection.OpenUniStreamSync(Context) (quic.SendStream, error) func github.com/quic-go/quic-go/http3.QUICEarlyListener.Accept(Context) (quic.EarlyConnection, error) func github.com/quic-go/quic-go/http3.RequestStream.ReceiveDatagram(Context) ([]byte, error) func github.com/quic-go/quic-go/http3.(*Server).Shutdown(ctx Context) error func github.com/quic-go/quic-go/http3.Stream.ReceiveDatagram(Context) ([]byte, error) func github.com/quic-go/quic-go/internal/handshake.CryptoSetup.StartHandshake(Context) error func github.com/quic-go/quic-go/metrics.DefaultConnectionTracer(_ Context, p logging.Perspective, _ logging.ConnectionID) *logging.ConnectionTracer func github.com/quic-go/quic-go/qlog.DefaultConnectionTracer(_ Context, p logging.Perspective, connID logging.ConnectionID) *logging.ConnectionTracer func github.com/quic-go/webtransport-go.(*Dialer).Dial(ctx Context, urlStr string, reqHdr http.Header) (*http.Response, *webtransport.Session, error) func github.com/quic-go/webtransport-go.(*Session).AcceptStream(ctx Context) (webtransport.Stream, error) func github.com/quic-go/webtransport-go.(*Session).AcceptUniStream(ctx Context) (webtransport.ReceiveStream, error) func github.com/quic-go/webtransport-go.(*Session).OpenStreamSync(ctx Context) (webtransport.Stream, error) func github.com/quic-go/webtransport-go.(*Session).OpenUniStreamSync(ctx Context) (str webtransport.SendStream, err error) func github.com/quic-go/webtransport-go.(*Session).ReceiveDatagram(ctx Context) ([]byte, error) func github.com/redis/go-redis/v9.NewBoolCmd(ctx Context, args ...interface{}) *redis.BoolCmd func github.com/redis/go-redis/v9.NewBoolSliceCmd(ctx Context, args ...interface{}) *redis.BoolSliceCmd func github.com/redis/go-redis/v9.NewClusterLinksCmd(ctx Context, args ...interface{}) *redis.ClusterLinksCmd func github.com/redis/go-redis/v9.NewClusterShardsCmd(ctx Context, args ...interface{}) *redis.ClusterShardsCmd func github.com/redis/go-redis/v9.NewClusterSlotsCmd(ctx Context, args ...interface{}) *redis.ClusterSlotsCmd func github.com/redis/go-redis/v9.NewCmd(ctx Context, args ...interface{}) *redis.Cmd func github.com/redis/go-redis/v9.NewCommandsInfoCmd(ctx Context, args ...interface{}) *redis.CommandsInfoCmd func github.com/redis/go-redis/v9.NewDurationCmd(ctx Context, precision time.Duration, args ...interface{}) *redis.DurationCmd func github.com/redis/go-redis/v9.NewFloatCmd(ctx Context, args ...interface{}) *redis.FloatCmd func github.com/redis/go-redis/v9.NewFloatSliceCmd(ctx Context, args ...interface{}) *redis.FloatSliceCmd func github.com/redis/go-redis/v9.NewFunctionListCmd(ctx Context, args ...interface{}) *redis.FunctionListCmd func github.com/redis/go-redis/v9.NewFunctionStatsCmd(ctx Context, args ...interface{}) *redis.FunctionStatsCmd func github.com/redis/go-redis/v9.NewGeoLocationCmd(ctx Context, q *redis.GeoRadiusQuery, args ...interface{}) *redis.GeoLocationCmd func github.com/redis/go-redis/v9.NewGeoPosCmd(ctx Context, args ...interface{}) *redis.GeoPosCmd func github.com/redis/go-redis/v9.NewGeoSearchLocationCmd(ctx Context, opt *redis.GeoSearchLocationQuery, args ...interface{}) *redis.GeoSearchLocationCmd func github.com/redis/go-redis/v9.NewIntCmd(ctx Context, args ...interface{}) *redis.IntCmd func github.com/redis/go-redis/v9.NewIntSliceCmd(ctx Context, args ...interface{}) *redis.IntSliceCmd func github.com/redis/go-redis/v9.NewKeyFlagsCmd(ctx Context, args ...interface{}) *redis.KeyFlagsCmd func github.com/redis/go-redis/v9.NewKeyValuesCmd(ctx Context, args ...interface{}) *redis.KeyValuesCmd func github.com/redis/go-redis/v9.NewKeyValueSliceCmd(ctx Context, args ...interface{}) *redis.KeyValueSliceCmd func github.com/redis/go-redis/v9.NewLCSCmd(ctx Context, q *redis.LCSQuery) *redis.LCSCmd func github.com/redis/go-redis/v9.NewMapStringIntCmd(ctx Context, args ...interface{}) *redis.MapStringIntCmd func github.com/redis/go-redis/v9.NewMapStringInterfaceCmd(ctx Context, args ...interface{}) *redis.MapStringInterfaceCmd func github.com/redis/go-redis/v9.NewMapStringStringCmd(ctx Context, args ...interface{}) *redis.MapStringStringCmd func github.com/redis/go-redis/v9.NewMapStringStringSliceCmd(ctx Context, args ...interface{}) *redis.MapStringStringSliceCmd func github.com/redis/go-redis/v9.NewScanCmd(ctx Context, process redis.cmdable, args ...interface{}) *redis.ScanCmd func github.com/redis/go-redis/v9.NewSliceCmd(ctx Context, args ...interface{}) *redis.SliceCmd func github.com/redis/go-redis/v9.NewSlowLogCmd(ctx Context, args ...interface{}) *redis.SlowLogCmd func github.com/redis/go-redis/v9.NewStatusCmd(ctx Context, args ...interface{}) *redis.StatusCmd func github.com/redis/go-redis/v9.NewStringCmd(ctx Context, args ...interface{}) *redis.StringCmd func github.com/redis/go-redis/v9.NewStringSliceCmd(ctx Context, args ...interface{}) *redis.StringSliceCmd func github.com/redis/go-redis/v9.NewStringStructMapCmd(ctx Context, args ...interface{}) *redis.StringStructMapCmd func github.com/redis/go-redis/v9.NewTimeCmd(ctx Context, args ...interface{}) *redis.TimeCmd func github.com/redis/go-redis/v9.NewXAutoClaimCmd(ctx Context, args ...interface{}) *redis.XAutoClaimCmd func github.com/redis/go-redis/v9.NewXAutoClaimJustIDCmd(ctx Context, args ...interface{}) *redis.XAutoClaimJustIDCmd func github.com/redis/go-redis/v9.NewXInfoConsumersCmd(ctx Context, stream string, group string) *redis.XInfoConsumersCmd func github.com/redis/go-redis/v9.NewXInfoGroupsCmd(ctx Context, stream string) *redis.XInfoGroupsCmd func github.com/redis/go-redis/v9.NewXInfoStreamCmd(ctx Context, stream string) *redis.XInfoStreamCmd func github.com/redis/go-redis/v9.NewXInfoStreamFullCmd(ctx Context, args ...interface{}) *redis.XInfoStreamFullCmd func github.com/redis/go-redis/v9.NewXMessageSliceCmd(ctx Context, args ...interface{}) *redis.XMessageSliceCmd func github.com/redis/go-redis/v9.NewXPendingCmd(ctx Context, args ...interface{}) *redis.XPendingCmd func github.com/redis/go-redis/v9.NewXPendingExtCmd(ctx Context, args ...interface{}) *redis.XPendingExtCmd func github.com/redis/go-redis/v9.NewXStreamSliceCmd(ctx Context, args ...interface{}) *redis.XStreamSliceCmd func github.com/redis/go-redis/v9.NewZSliceCmd(ctx Context, args ...interface{}) *redis.ZSliceCmd func github.com/redis/go-redis/v9.NewZSliceWithKeyCmd(ctx Context, args ...interface{}) *redis.ZSliceWithKeyCmd func github.com/redis/go-redis/v9.NewZWithKeyCmd(ctx Context, args ...interface{}) *redis.ZWithKeyCmd func github.com/redis/go-redis/v9.(*Client).Do(ctx Context, args ...interface{}) *redis.Cmd func github.com/redis/go-redis/v9.(*Client).Pipelined(ctx Context, fn func(redis.Pipeliner) error) ([]redis.Cmder, error) func github.com/redis/go-redis/v9.(*Client).Process(ctx Context, cmd redis.Cmder) error func github.com/redis/go-redis/v9.(*Client).PSubscribe(ctx Context, channels ...string) *redis.PubSub func github.com/redis/go-redis/v9.(*Client).SSubscribe(ctx Context, channels ...string) *redis.PubSub func github.com/redis/go-redis/v9.(*Client).Subscribe(ctx Context, channels ...string) *redis.PubSub func github.com/redis/go-redis/v9.(*Client).TxPipelined(ctx Context, fn func(redis.Pipeliner) error) ([]redis.Cmder, error) func github.com/redis/go-redis/v9.(*Client).Watch(ctx Context, fn func(*redis.Tx) error, keys ...string) error func github.com/redis/go-redis/v9.(*ClusterClient).DBSize(ctx Context) *redis.IntCmd func github.com/redis/go-redis/v9.(*ClusterClient).Do(ctx Context, args ...interface{}) *redis.Cmd func github.com/redis/go-redis/v9.(*ClusterClient).ForEachMaster(ctx Context, fn func(ctx Context, client *redis.Client) error) error func github.com/redis/go-redis/v9.(*ClusterClient).ForEachShard(ctx Context, fn func(ctx Context, client *redis.Client) error) error func github.com/redis/go-redis/v9.(*ClusterClient).ForEachSlave(ctx Context, fn func(ctx Context, client *redis.Client) error) error func github.com/redis/go-redis/v9.(*ClusterClient).MasterForKey(ctx Context, key string) (*redis.Client, error) func github.com/redis/go-redis/v9.(*ClusterClient).Pipelined(ctx Context, fn func(redis.Pipeliner) error) ([]redis.Cmder, error) func github.com/redis/go-redis/v9.(*ClusterClient).Process(ctx Context, cmd redis.Cmder) error func github.com/redis/go-redis/v9.(*ClusterClient).PSubscribe(ctx Context, channels ...string) *redis.PubSub func github.com/redis/go-redis/v9.(*ClusterClient).ReloadState(ctx Context) func github.com/redis/go-redis/v9.(*ClusterClient).ScriptExists(ctx Context, hashes ...string) *redis.BoolSliceCmd func github.com/redis/go-redis/v9.(*ClusterClient).ScriptFlush(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.(*ClusterClient).ScriptLoad(ctx Context, script string) *redis.StringCmd func github.com/redis/go-redis/v9.(*ClusterClient).SlaveForKey(ctx Context, key string) (*redis.Client, error) func github.com/redis/go-redis/v9.(*ClusterClient).SSubscribe(ctx Context, channels ...string) *redis.PubSub func github.com/redis/go-redis/v9.(*ClusterClient).Subscribe(ctx Context, channels ...string) *redis.PubSub func github.com/redis/go-redis/v9.(*ClusterClient).TxPipelined(ctx Context, fn func(redis.Pipeliner) error) ([]redis.Cmder, error) func github.com/redis/go-redis/v9.(*ClusterClient).Watch(ctx Context, fn func(*redis.Tx) error, keys ...string) error func github.com/redis/go-redis/v9.Cmdable.ACLDryRun(ctx Context, username string, command ...interface{}) *redis.StringCmd func github.com/redis/go-redis/v9.Cmdable.Append(ctx Context, key, value string) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.BgRewriteAOF(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.Cmdable.BgSave(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.Cmdable.BitCount(ctx Context, key string, bitCount *redis.BitCount) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.BitField(ctx Context, key string, args ...interface{}) *redis.IntSliceCmd func github.com/redis/go-redis/v9.Cmdable.BitOpAnd(ctx Context, destKey string, keys ...string) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.BitOpNot(ctx Context, destKey string, key string) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.BitOpOr(ctx Context, destKey string, keys ...string) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.BitOpXor(ctx Context, destKey string, keys ...string) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.BitPos(ctx Context, key string, bit int64, pos ...int64) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.BitPosSpan(ctx Context, key string, bit int8, start, end int64, span string) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.BLMove(ctx Context, source, destination, srcpos, destpos string, timeout time.Duration) *redis.StringCmd func github.com/redis/go-redis/v9.Cmdable.BLMPop(ctx Context, timeout time.Duration, direction string, count int64, keys ...string) *redis.KeyValuesCmd func github.com/redis/go-redis/v9.Cmdable.BLPop(ctx Context, timeout time.Duration, keys ...string) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Cmdable.BRPop(ctx Context, timeout time.Duration, keys ...string) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Cmdable.BRPopLPush(ctx Context, source, destination string, timeout time.Duration) *redis.StringCmd func github.com/redis/go-redis/v9.Cmdable.BZMPop(ctx Context, timeout time.Duration, order string, count int64, keys ...string) *redis.ZSliceWithKeyCmd func github.com/redis/go-redis/v9.Cmdable.BZPopMax(ctx Context, timeout time.Duration, keys ...string) *redis.ZWithKeyCmd func github.com/redis/go-redis/v9.Cmdable.BZPopMin(ctx Context, timeout time.Duration, keys ...string) *redis.ZWithKeyCmd func github.com/redis/go-redis/v9.Cmdable.ClientGetName(ctx Context) *redis.StringCmd func github.com/redis/go-redis/v9.Cmdable.ClientID(ctx Context) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.ClientKill(ctx Context, ipPort string) *redis.StatusCmd func github.com/redis/go-redis/v9.Cmdable.ClientKillByFilter(ctx Context, keys ...string) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.ClientList(ctx Context) *redis.StringCmd func github.com/redis/go-redis/v9.Cmdable.ClientPause(ctx Context, dur time.Duration) *redis.BoolCmd func github.com/redis/go-redis/v9.Cmdable.ClientUnblock(ctx Context, id int64) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.ClientUnblockWithError(ctx Context, id int64) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.ClientUnpause(ctx Context) *redis.BoolCmd func github.com/redis/go-redis/v9.Cmdable.ClusterAddSlots(ctx Context, slots ...int) *redis.StatusCmd func github.com/redis/go-redis/v9.Cmdable.ClusterAddSlotsRange(ctx Context, min, max int) *redis.StatusCmd func github.com/redis/go-redis/v9.Cmdable.ClusterCountFailureReports(ctx Context, nodeID string) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.ClusterCountKeysInSlot(ctx Context, slot int) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.ClusterDelSlots(ctx Context, slots ...int) *redis.StatusCmd func github.com/redis/go-redis/v9.Cmdable.ClusterDelSlotsRange(ctx Context, min, max int) *redis.StatusCmd func github.com/redis/go-redis/v9.Cmdable.ClusterFailover(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.Cmdable.ClusterForget(ctx Context, nodeID string) *redis.StatusCmd func github.com/redis/go-redis/v9.Cmdable.ClusterGetKeysInSlot(ctx Context, slot int, count int) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Cmdable.ClusterInfo(ctx Context) *redis.StringCmd func github.com/redis/go-redis/v9.Cmdable.ClusterKeySlot(ctx Context, key string) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.ClusterLinks(ctx Context) *redis.ClusterLinksCmd func github.com/redis/go-redis/v9.Cmdable.ClusterMeet(ctx Context, host, port string) *redis.StatusCmd func github.com/redis/go-redis/v9.Cmdable.ClusterNodes(ctx Context) *redis.StringCmd func github.com/redis/go-redis/v9.Cmdable.ClusterReplicate(ctx Context, nodeID string) *redis.StatusCmd func github.com/redis/go-redis/v9.Cmdable.ClusterResetHard(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.Cmdable.ClusterResetSoft(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.Cmdable.ClusterSaveConfig(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.Cmdable.ClusterShards(ctx Context) *redis.ClusterShardsCmd func github.com/redis/go-redis/v9.Cmdable.ClusterSlaves(ctx Context, nodeID string) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Cmdable.ClusterSlots(ctx Context) *redis.ClusterSlotsCmd func github.com/redis/go-redis/v9.Cmdable.Command(ctx Context) *redis.CommandsInfoCmd func github.com/redis/go-redis/v9.Cmdable.CommandGetKeys(ctx Context, commands ...interface{}) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Cmdable.CommandGetKeysAndFlags(ctx Context, commands ...interface{}) *redis.KeyFlagsCmd func github.com/redis/go-redis/v9.Cmdable.CommandList(ctx Context, filter *redis.FilterBy) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Cmdable.ConfigGet(ctx Context, parameter string) *redis.MapStringStringCmd func github.com/redis/go-redis/v9.Cmdable.ConfigResetStat(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.Cmdable.ConfigRewrite(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.Cmdable.ConfigSet(ctx Context, parameter, value string) *redis.StatusCmd func github.com/redis/go-redis/v9.Cmdable.Copy(ctx Context, sourceKey string, destKey string, db int, replace bool) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.DBSize(ctx Context) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.DebugObject(ctx Context, key string) *redis.StringCmd func github.com/redis/go-redis/v9.Cmdable.Decr(ctx Context, key string) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.DecrBy(ctx Context, key string, decrement int64) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.Del(ctx Context, keys ...string) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.Dump(ctx Context, key string) *redis.StringCmd func github.com/redis/go-redis/v9.Cmdable.Echo(ctx Context, message interface{}) *redis.StringCmd func github.com/redis/go-redis/v9.Cmdable.Eval(ctx Context, script string, keys []string, args ...interface{}) *redis.Cmd func github.com/redis/go-redis/v9.Cmdable.EvalRO(ctx Context, script string, keys []string, args ...interface{}) *redis.Cmd func github.com/redis/go-redis/v9.Cmdable.EvalSha(ctx Context, sha1 string, keys []string, args ...interface{}) *redis.Cmd func github.com/redis/go-redis/v9.Cmdable.EvalShaRO(ctx Context, sha1 string, keys []string, args ...interface{}) *redis.Cmd func github.com/redis/go-redis/v9.Cmdable.Exists(ctx Context, keys ...string) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.Expire(ctx Context, key string, expiration time.Duration) *redis.BoolCmd func github.com/redis/go-redis/v9.Cmdable.ExpireAt(ctx Context, key string, tm time.Time) *redis.BoolCmd func github.com/redis/go-redis/v9.Cmdable.ExpireGT(ctx Context, key string, expiration time.Duration) *redis.BoolCmd func github.com/redis/go-redis/v9.Cmdable.ExpireLT(ctx Context, key string, expiration time.Duration) *redis.BoolCmd func github.com/redis/go-redis/v9.Cmdable.ExpireNX(ctx Context, key string, expiration time.Duration) *redis.BoolCmd func github.com/redis/go-redis/v9.Cmdable.ExpireTime(ctx Context, key string) *redis.DurationCmd func github.com/redis/go-redis/v9.Cmdable.ExpireXX(ctx Context, key string, expiration time.Duration) *redis.BoolCmd func github.com/redis/go-redis/v9.Cmdable.FCall(ctx Context, function string, keys []string, args ...interface{}) *redis.Cmd func github.com/redis/go-redis/v9.Cmdable.FCallRo(ctx Context, function string, keys []string, args ...interface{}) *redis.Cmd func github.com/redis/go-redis/v9.Cmdable.FlushAll(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.Cmdable.FlushAllAsync(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.Cmdable.FlushDB(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.Cmdable.FlushDBAsync(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.Cmdable.FunctionDelete(ctx Context, libName string) *redis.StringCmd func github.com/redis/go-redis/v9.Cmdable.FunctionDump(ctx Context) *redis.StringCmd func github.com/redis/go-redis/v9.Cmdable.FunctionFlush(ctx Context) *redis.StringCmd func github.com/redis/go-redis/v9.Cmdable.FunctionFlushAsync(ctx Context) *redis.StringCmd func github.com/redis/go-redis/v9.Cmdable.FunctionKill(ctx Context) *redis.StringCmd func github.com/redis/go-redis/v9.Cmdable.FunctionList(ctx Context, q redis.FunctionListQuery) *redis.FunctionListCmd func github.com/redis/go-redis/v9.Cmdable.FunctionLoad(ctx Context, code string) *redis.StringCmd func github.com/redis/go-redis/v9.Cmdable.FunctionLoadReplace(ctx Context, code string) *redis.StringCmd func github.com/redis/go-redis/v9.Cmdable.FunctionRestore(ctx Context, libDump string) *redis.StringCmd func github.com/redis/go-redis/v9.Cmdable.FunctionStats(ctx Context) *redis.FunctionStatsCmd func github.com/redis/go-redis/v9.Cmdable.GeoAdd(ctx Context, key string, geoLocation ...*redis.GeoLocation) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.GeoDist(ctx Context, key string, member1, member2, unit string) *redis.FloatCmd func github.com/redis/go-redis/v9.Cmdable.GeoHash(ctx Context, key string, members ...string) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Cmdable.GeoPos(ctx Context, key string, members ...string) *redis.GeoPosCmd func github.com/redis/go-redis/v9.Cmdable.GeoRadius(ctx Context, key string, longitude, latitude float64, query *redis.GeoRadiusQuery) *redis.GeoLocationCmd func github.com/redis/go-redis/v9.Cmdable.GeoRadiusByMember(ctx Context, key, member string, query *redis.GeoRadiusQuery) *redis.GeoLocationCmd func github.com/redis/go-redis/v9.Cmdable.GeoRadiusByMemberStore(ctx Context, key, member string, query *redis.GeoRadiusQuery) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.GeoRadiusStore(ctx Context, key string, longitude, latitude float64, query *redis.GeoRadiusQuery) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.GeoSearch(ctx Context, key string, q *redis.GeoSearchQuery) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Cmdable.GeoSearchLocation(ctx Context, key string, q *redis.GeoSearchLocationQuery) *redis.GeoSearchLocationCmd func github.com/redis/go-redis/v9.Cmdable.GeoSearchStore(ctx Context, key, store string, q *redis.GeoSearchStoreQuery) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.Get(ctx Context, key string) *redis.StringCmd func github.com/redis/go-redis/v9.Cmdable.GetBit(ctx Context, key string, offset int64) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.GetDel(ctx Context, key string) *redis.StringCmd func github.com/redis/go-redis/v9.Cmdable.GetEx(ctx Context, key string, expiration time.Duration) *redis.StringCmd func github.com/redis/go-redis/v9.Cmdable.GetRange(ctx Context, key string, start, end int64) *redis.StringCmd func github.com/redis/go-redis/v9.Cmdable.GetSet(ctx Context, key string, value interface{}) *redis.StringCmd func github.com/redis/go-redis/v9.Cmdable.HDel(ctx Context, key string, fields ...string) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.HExists(ctx Context, key, field string) *redis.BoolCmd func github.com/redis/go-redis/v9.Cmdable.HGet(ctx Context, key, field string) *redis.StringCmd func github.com/redis/go-redis/v9.Cmdable.HGetAll(ctx Context, key string) *redis.MapStringStringCmd func github.com/redis/go-redis/v9.Cmdable.HIncrBy(ctx Context, key, field string, incr int64) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.HIncrByFloat(ctx Context, key, field string, incr float64) *redis.FloatCmd func github.com/redis/go-redis/v9.Cmdable.HKeys(ctx Context, key string) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Cmdable.HLen(ctx Context, key string) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.HMGet(ctx Context, key string, fields ...string) *redis.SliceCmd func github.com/redis/go-redis/v9.Cmdable.HMSet(ctx Context, key string, values ...interface{}) *redis.BoolCmd func github.com/redis/go-redis/v9.Cmdable.HRandField(ctx Context, key string, count int) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Cmdable.HRandFieldWithValues(ctx Context, key string, count int) *redis.KeyValueSliceCmd func github.com/redis/go-redis/v9.Cmdable.HScan(ctx Context, key string, cursor uint64, match string, count int64) *redis.ScanCmd func github.com/redis/go-redis/v9.Cmdable.HSet(ctx Context, key string, values ...interface{}) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.HSetNX(ctx Context, key, field string, value interface{}) *redis.BoolCmd func github.com/redis/go-redis/v9.Cmdable.HVals(ctx Context, key string) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Cmdable.Incr(ctx Context, key string) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.IncrBy(ctx Context, key string, value int64) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.IncrByFloat(ctx Context, key string, value float64) *redis.FloatCmd func github.com/redis/go-redis/v9.Cmdable.Info(ctx Context, section ...string) *redis.StringCmd func github.com/redis/go-redis/v9.Cmdable.Keys(ctx Context, pattern string) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Cmdable.LastSave(ctx Context) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.LCS(ctx Context, q *redis.LCSQuery) *redis.LCSCmd func github.com/redis/go-redis/v9.Cmdable.LIndex(ctx Context, key string, index int64) *redis.StringCmd func github.com/redis/go-redis/v9.Cmdable.LInsert(ctx Context, key, op string, pivot, value interface{}) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.LInsertAfter(ctx Context, key string, pivot, value interface{}) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.LInsertBefore(ctx Context, key string, pivot, value interface{}) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.LLen(ctx Context, key string) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.LMove(ctx Context, source, destination, srcpos, destpos string) *redis.StringCmd func github.com/redis/go-redis/v9.Cmdable.LMPop(ctx Context, direction string, count int64, keys ...string) *redis.KeyValuesCmd func github.com/redis/go-redis/v9.Cmdable.LPop(ctx Context, key string) *redis.StringCmd func github.com/redis/go-redis/v9.Cmdable.LPopCount(ctx Context, key string, count int) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Cmdable.LPos(ctx Context, key string, value string, args redis.LPosArgs) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.LPosCount(ctx Context, key string, value string, count int64, args redis.LPosArgs) *redis.IntSliceCmd func github.com/redis/go-redis/v9.Cmdable.LPush(ctx Context, key string, values ...interface{}) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.LPushX(ctx Context, key string, values ...interface{}) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.LRange(ctx Context, key string, start, stop int64) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Cmdable.LRem(ctx Context, key string, count int64, value interface{}) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.LSet(ctx Context, key string, index int64, value interface{}) *redis.StatusCmd func github.com/redis/go-redis/v9.Cmdable.LTrim(ctx Context, key string, start, stop int64) *redis.StatusCmd func github.com/redis/go-redis/v9.Cmdable.MemoryUsage(ctx Context, key string, samples ...int) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.MGet(ctx Context, keys ...string) *redis.SliceCmd func github.com/redis/go-redis/v9.Cmdable.Migrate(ctx Context, host, port, key string, db int, timeout time.Duration) *redis.StatusCmd func github.com/redis/go-redis/v9.Cmdable.Move(ctx Context, key string, db int) *redis.BoolCmd func github.com/redis/go-redis/v9.Cmdable.MSet(ctx Context, values ...interface{}) *redis.StatusCmd func github.com/redis/go-redis/v9.Cmdable.MSetNX(ctx Context, values ...interface{}) *redis.BoolCmd func github.com/redis/go-redis/v9.Cmdable.ObjectEncoding(ctx Context, key string) *redis.StringCmd func github.com/redis/go-redis/v9.Cmdable.ObjectIdleTime(ctx Context, key string) *redis.DurationCmd func github.com/redis/go-redis/v9.Cmdable.ObjectRefCount(ctx Context, key string) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.Persist(ctx Context, key string) *redis.BoolCmd func github.com/redis/go-redis/v9.Cmdable.PExpire(ctx Context, key string, expiration time.Duration) *redis.BoolCmd func github.com/redis/go-redis/v9.Cmdable.PExpireAt(ctx Context, key string, tm time.Time) *redis.BoolCmd func github.com/redis/go-redis/v9.Cmdable.PExpireTime(ctx Context, key string) *redis.DurationCmd func github.com/redis/go-redis/v9.Cmdable.PFAdd(ctx Context, key string, els ...interface{}) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.PFCount(ctx Context, keys ...string) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.PFMerge(ctx Context, dest string, keys ...string) *redis.StatusCmd func github.com/redis/go-redis/v9.Cmdable.Ping(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.Cmdable.Pipelined(ctx Context, fn func(redis.Pipeliner) error) ([]redis.Cmder, error) func github.com/redis/go-redis/v9.Cmdable.PTTL(ctx Context, key string) *redis.DurationCmd func github.com/redis/go-redis/v9.Cmdable.Publish(ctx Context, channel string, message interface{}) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.PubSubChannels(ctx Context, pattern string) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Cmdable.PubSubNumPat(ctx Context) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.PubSubNumSub(ctx Context, channels ...string) *redis.MapStringIntCmd func github.com/redis/go-redis/v9.Cmdable.PubSubShardChannels(ctx Context, pattern string) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Cmdable.PubSubShardNumSub(ctx Context, channels ...string) *redis.MapStringIntCmd func github.com/redis/go-redis/v9.Cmdable.Quit(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.Cmdable.RandomKey(ctx Context) *redis.StringCmd func github.com/redis/go-redis/v9.Cmdable.ReadOnly(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.Cmdable.ReadWrite(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.Cmdable.Rename(ctx Context, key, newkey string) *redis.StatusCmd func github.com/redis/go-redis/v9.Cmdable.RenameNX(ctx Context, key, newkey string) *redis.BoolCmd func github.com/redis/go-redis/v9.Cmdable.Restore(ctx Context, key string, ttl time.Duration, value string) *redis.StatusCmd func github.com/redis/go-redis/v9.Cmdable.RestoreReplace(ctx Context, key string, ttl time.Duration, value string) *redis.StatusCmd func github.com/redis/go-redis/v9.Cmdable.RPop(ctx Context, key string) *redis.StringCmd func github.com/redis/go-redis/v9.Cmdable.RPopCount(ctx Context, key string, count int) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Cmdable.RPopLPush(ctx Context, source, destination string) *redis.StringCmd func github.com/redis/go-redis/v9.Cmdable.RPush(ctx Context, key string, values ...interface{}) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.RPushX(ctx Context, key string, values ...interface{}) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.SAdd(ctx Context, key string, members ...interface{}) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.Save(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.Cmdable.Scan(ctx Context, cursor uint64, match string, count int64) *redis.ScanCmd func github.com/redis/go-redis/v9.Cmdable.ScanType(ctx Context, cursor uint64, match string, count int64, keyType string) *redis.ScanCmd func github.com/redis/go-redis/v9.Cmdable.SCard(ctx Context, key string) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.ScriptExists(ctx Context, hashes ...string) *redis.BoolSliceCmd func github.com/redis/go-redis/v9.Cmdable.ScriptFlush(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.Cmdable.ScriptKill(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.Cmdable.ScriptLoad(ctx Context, script string) *redis.StringCmd func github.com/redis/go-redis/v9.Cmdable.SDiff(ctx Context, keys ...string) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Cmdable.SDiffStore(ctx Context, destination string, keys ...string) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.Set(ctx Context, key string, value interface{}, expiration time.Duration) *redis.StatusCmd func github.com/redis/go-redis/v9.Cmdable.SetArgs(ctx Context, key string, value interface{}, a redis.SetArgs) *redis.StatusCmd func github.com/redis/go-redis/v9.Cmdable.SetBit(ctx Context, key string, offset int64, value int) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.SetEx(ctx Context, key string, value interface{}, expiration time.Duration) *redis.StatusCmd func github.com/redis/go-redis/v9.Cmdable.SetNX(ctx Context, key string, value interface{}, expiration time.Duration) *redis.BoolCmd func github.com/redis/go-redis/v9.Cmdable.SetRange(ctx Context, key string, offset int64, value string) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.SetXX(ctx Context, key string, value interface{}, expiration time.Duration) *redis.BoolCmd func github.com/redis/go-redis/v9.Cmdable.Shutdown(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.Cmdable.ShutdownNoSave(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.Cmdable.ShutdownSave(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.Cmdable.SInter(ctx Context, keys ...string) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Cmdable.SInterCard(ctx Context, limit int64, keys ...string) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.SInterStore(ctx Context, destination string, keys ...string) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.SIsMember(ctx Context, key string, member interface{}) *redis.BoolCmd func github.com/redis/go-redis/v9.Cmdable.SlaveOf(ctx Context, host, port string) *redis.StatusCmd func github.com/redis/go-redis/v9.Cmdable.SlowLogGet(ctx Context, num int64) *redis.SlowLogCmd func github.com/redis/go-redis/v9.Cmdable.SMembers(ctx Context, key string) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Cmdable.SMembersMap(ctx Context, key string) *redis.StringStructMapCmd func github.com/redis/go-redis/v9.Cmdable.SMIsMember(ctx Context, key string, members ...interface{}) *redis.BoolSliceCmd func github.com/redis/go-redis/v9.Cmdable.SMove(ctx Context, source, destination string, member interface{}) *redis.BoolCmd func github.com/redis/go-redis/v9.Cmdable.Sort(ctx Context, key string, sort *redis.Sort) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Cmdable.SortInterfaces(ctx Context, key string, sort *redis.Sort) *redis.SliceCmd func github.com/redis/go-redis/v9.Cmdable.SortRO(ctx Context, key string, sort *redis.Sort) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Cmdable.SortStore(ctx Context, key, store string, sort *redis.Sort) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.SPop(ctx Context, key string) *redis.StringCmd func github.com/redis/go-redis/v9.Cmdable.SPopN(ctx Context, key string, count int64) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Cmdable.SPublish(ctx Context, channel string, message interface{}) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.SRandMember(ctx Context, key string) *redis.StringCmd func github.com/redis/go-redis/v9.Cmdable.SRandMemberN(ctx Context, key string, count int64) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Cmdable.SRem(ctx Context, key string, members ...interface{}) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.SScan(ctx Context, key string, cursor uint64, match string, count int64) *redis.ScanCmd func github.com/redis/go-redis/v9.Cmdable.StrLen(ctx Context, key string) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.SUnion(ctx Context, keys ...string) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Cmdable.SUnionStore(ctx Context, destination string, keys ...string) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.Time(ctx Context) *redis.TimeCmd func github.com/redis/go-redis/v9.Cmdable.Touch(ctx Context, keys ...string) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.TTL(ctx Context, key string) *redis.DurationCmd func github.com/redis/go-redis/v9.Cmdable.TxPipelined(ctx Context, fn func(redis.Pipeliner) error) ([]redis.Cmder, error) func github.com/redis/go-redis/v9.Cmdable.Type(ctx Context, key string) *redis.StatusCmd func github.com/redis/go-redis/v9.Cmdable.Unlink(ctx Context, keys ...string) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.XAck(ctx Context, stream, group string, ids ...string) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.XAdd(ctx Context, a *redis.XAddArgs) *redis.StringCmd func github.com/redis/go-redis/v9.Cmdable.XAutoClaim(ctx Context, a *redis.XAutoClaimArgs) *redis.XAutoClaimCmd func github.com/redis/go-redis/v9.Cmdable.XAutoClaimJustID(ctx Context, a *redis.XAutoClaimArgs) *redis.XAutoClaimJustIDCmd func github.com/redis/go-redis/v9.Cmdable.XClaim(ctx Context, a *redis.XClaimArgs) *redis.XMessageSliceCmd func github.com/redis/go-redis/v9.Cmdable.XClaimJustID(ctx Context, a *redis.XClaimArgs) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Cmdable.XDel(ctx Context, stream string, ids ...string) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.XGroupCreate(ctx Context, stream, group, start string) *redis.StatusCmd func github.com/redis/go-redis/v9.Cmdable.XGroupCreateConsumer(ctx Context, stream, group, consumer string) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.XGroupCreateMkStream(ctx Context, stream, group, start string) *redis.StatusCmd func github.com/redis/go-redis/v9.Cmdable.XGroupDelConsumer(ctx Context, stream, group, consumer string) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.XGroupDestroy(ctx Context, stream, group string) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.XGroupSetID(ctx Context, stream, group, start string) *redis.StatusCmd func github.com/redis/go-redis/v9.Cmdable.XInfoConsumers(ctx Context, key string, group string) *redis.XInfoConsumersCmd func github.com/redis/go-redis/v9.Cmdable.XInfoGroups(ctx Context, key string) *redis.XInfoGroupsCmd func github.com/redis/go-redis/v9.Cmdable.XInfoStream(ctx Context, key string) *redis.XInfoStreamCmd func github.com/redis/go-redis/v9.Cmdable.XInfoStreamFull(ctx Context, key string, count int) *redis.XInfoStreamFullCmd func github.com/redis/go-redis/v9.Cmdable.XLen(ctx Context, stream string) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.XPending(ctx Context, stream, group string) *redis.XPendingCmd func github.com/redis/go-redis/v9.Cmdable.XPendingExt(ctx Context, a *redis.XPendingExtArgs) *redis.XPendingExtCmd func github.com/redis/go-redis/v9.Cmdable.XRange(ctx Context, stream, start, stop string) *redis.XMessageSliceCmd func github.com/redis/go-redis/v9.Cmdable.XRangeN(ctx Context, stream, start, stop string, count int64) *redis.XMessageSliceCmd func github.com/redis/go-redis/v9.Cmdable.XRead(ctx Context, a *redis.XReadArgs) *redis.XStreamSliceCmd func github.com/redis/go-redis/v9.Cmdable.XReadGroup(ctx Context, a *redis.XReadGroupArgs) *redis.XStreamSliceCmd func github.com/redis/go-redis/v9.Cmdable.XReadStreams(ctx Context, streams ...string) *redis.XStreamSliceCmd func github.com/redis/go-redis/v9.Cmdable.XRevRange(ctx Context, stream string, start, stop string) *redis.XMessageSliceCmd func github.com/redis/go-redis/v9.Cmdable.XRevRangeN(ctx Context, stream string, start, stop string, count int64) *redis.XMessageSliceCmd func github.com/redis/go-redis/v9.Cmdable.XTrimMaxLen(ctx Context, key string, maxLen int64) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.XTrimMaxLenApprox(ctx Context, key string, maxLen, limit int64) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.XTrimMinID(ctx Context, key string, minID string) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.XTrimMinIDApprox(ctx Context, key string, minID string, limit int64) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.ZAdd(ctx Context, key string, members ...redis.Z) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.ZAddArgs(ctx Context, key string, args redis.ZAddArgs) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.ZAddArgsIncr(ctx Context, key string, args redis.ZAddArgs) *redis.FloatCmd func github.com/redis/go-redis/v9.Cmdable.ZAddGT(ctx Context, key string, members ...redis.Z) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.ZAddLT(ctx Context, key string, members ...redis.Z) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.ZAddNX(ctx Context, key string, members ...redis.Z) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.ZAddXX(ctx Context, key string, members ...redis.Z) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.ZCard(ctx Context, key string) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.ZCount(ctx Context, key, min, max string) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.ZDiff(ctx Context, keys ...string) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Cmdable.ZDiffStore(ctx Context, destination string, keys ...string) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.ZDiffWithScores(ctx Context, keys ...string) *redis.ZSliceCmd func github.com/redis/go-redis/v9.Cmdable.ZIncrBy(ctx Context, key string, increment float64, member string) *redis.FloatCmd func github.com/redis/go-redis/v9.Cmdable.ZInter(ctx Context, store *redis.ZStore) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Cmdable.ZInterCard(ctx Context, limit int64, keys ...string) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.ZInterStore(ctx Context, destination string, store *redis.ZStore) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.ZInterWithScores(ctx Context, store *redis.ZStore) *redis.ZSliceCmd func github.com/redis/go-redis/v9.Cmdable.ZLexCount(ctx Context, key, min, max string) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.ZMPop(ctx Context, order string, count int64, keys ...string) *redis.ZSliceWithKeyCmd func github.com/redis/go-redis/v9.Cmdable.ZMScore(ctx Context, key string, members ...string) *redis.FloatSliceCmd func github.com/redis/go-redis/v9.Cmdable.ZPopMax(ctx Context, key string, count ...int64) *redis.ZSliceCmd func github.com/redis/go-redis/v9.Cmdable.ZPopMin(ctx Context, key string, count ...int64) *redis.ZSliceCmd func github.com/redis/go-redis/v9.Cmdable.ZRandMember(ctx Context, key string, count int) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Cmdable.ZRandMemberWithScores(ctx Context, key string, count int) *redis.ZSliceCmd func github.com/redis/go-redis/v9.Cmdable.ZRange(ctx Context, key string, start, stop int64) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Cmdable.ZRangeArgs(ctx Context, z redis.ZRangeArgs) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Cmdable.ZRangeArgsWithScores(ctx Context, z redis.ZRangeArgs) *redis.ZSliceCmd func github.com/redis/go-redis/v9.Cmdable.ZRangeByLex(ctx Context, key string, opt *redis.ZRangeBy) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Cmdable.ZRangeByScore(ctx Context, key string, opt *redis.ZRangeBy) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Cmdable.ZRangeByScoreWithScores(ctx Context, key string, opt *redis.ZRangeBy) *redis.ZSliceCmd func github.com/redis/go-redis/v9.Cmdable.ZRangeStore(ctx Context, dst string, z redis.ZRangeArgs) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.ZRangeWithScores(ctx Context, key string, start, stop int64) *redis.ZSliceCmd func github.com/redis/go-redis/v9.Cmdable.ZRank(ctx Context, key, member string) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.ZRem(ctx Context, key string, members ...interface{}) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.ZRemRangeByLex(ctx Context, key, min, max string) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.ZRemRangeByRank(ctx Context, key string, start, stop int64) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.ZRemRangeByScore(ctx Context, key, min, max string) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.ZRevRange(ctx Context, key string, start, stop int64) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Cmdable.ZRevRangeByLex(ctx Context, key string, opt *redis.ZRangeBy) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Cmdable.ZRevRangeByScore(ctx Context, key string, opt *redis.ZRangeBy) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Cmdable.ZRevRangeByScoreWithScores(ctx Context, key string, opt *redis.ZRangeBy) *redis.ZSliceCmd func github.com/redis/go-redis/v9.Cmdable.ZRevRangeWithScores(ctx Context, key string, start, stop int64) *redis.ZSliceCmd func github.com/redis/go-redis/v9.Cmdable.ZRevRank(ctx Context, key, member string) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.ZScan(ctx Context, key string, cursor uint64, match string, count int64) *redis.ScanCmd func github.com/redis/go-redis/v9.Cmdable.ZScore(ctx Context, key, member string) *redis.FloatCmd func github.com/redis/go-redis/v9.Cmdable.ZUnion(ctx Context, store redis.ZStore) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Cmdable.ZUnionStore(ctx Context, dest string, store *redis.ZStore) *redis.IntCmd func github.com/redis/go-redis/v9.Cmdable.ZUnionWithScores(ctx Context, store redis.ZStore) *redis.ZSliceCmd func github.com/redis/go-redis/v9.(*Conn).Pipelined(ctx Context, fn func(redis.Pipeliner) error) ([]redis.Cmder, error) func github.com/redis/go-redis/v9.(*Conn).Process(ctx Context, cmd redis.Cmder) error func github.com/redis/go-redis/v9.(*Conn).TxPipelined(ctx Context, fn func(redis.Pipeliner) error) ([]redis.Cmder, error) func github.com/redis/go-redis/v9.(*Pipeline).Do(ctx Context, args ...interface{}) *redis.Cmd func github.com/redis/go-redis/v9.(*Pipeline).Exec(ctx Context) ([]redis.Cmder, error) func github.com/redis/go-redis/v9.(*Pipeline).Pipelined(ctx Context, fn func(redis.Pipeliner) error) ([]redis.Cmder, error) func github.com/redis/go-redis/v9.(*Pipeline).Process(ctx Context, cmd redis.Cmder) error func github.com/redis/go-redis/v9.(*Pipeline).TxPipelined(ctx Context, fn func(redis.Pipeliner) error) ([]redis.Cmder, error) func github.com/redis/go-redis/v9.Pipeliner.ACLDryRun(ctx Context, username string, command ...interface{}) *redis.StringCmd func github.com/redis/go-redis/v9.Pipeliner.Append(ctx Context, key, value string) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.Auth(ctx Context, password string) *redis.StatusCmd func github.com/redis/go-redis/v9.Pipeliner.AuthACL(ctx Context, username, password string) *redis.StatusCmd func github.com/redis/go-redis/v9.Pipeliner.BgRewriteAOF(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.Pipeliner.BgSave(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.Pipeliner.BitCount(ctx Context, key string, bitCount *redis.BitCount) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.BitField(ctx Context, key string, args ...interface{}) *redis.IntSliceCmd func github.com/redis/go-redis/v9.Pipeliner.BitOpAnd(ctx Context, destKey string, keys ...string) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.BitOpNot(ctx Context, destKey string, key string) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.BitOpOr(ctx Context, destKey string, keys ...string) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.BitOpXor(ctx Context, destKey string, keys ...string) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.BitPos(ctx Context, key string, bit int64, pos ...int64) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.BitPosSpan(ctx Context, key string, bit int8, start, end int64, span string) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.BLMove(ctx Context, source, destination, srcpos, destpos string, timeout time.Duration) *redis.StringCmd func github.com/redis/go-redis/v9.Pipeliner.BLMPop(ctx Context, timeout time.Duration, direction string, count int64, keys ...string) *redis.KeyValuesCmd func github.com/redis/go-redis/v9.Pipeliner.BLPop(ctx Context, timeout time.Duration, keys ...string) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Pipeliner.BRPop(ctx Context, timeout time.Duration, keys ...string) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Pipeliner.BRPopLPush(ctx Context, source, destination string, timeout time.Duration) *redis.StringCmd func github.com/redis/go-redis/v9.Pipeliner.BZMPop(ctx Context, timeout time.Duration, order string, count int64, keys ...string) *redis.ZSliceWithKeyCmd func github.com/redis/go-redis/v9.Pipeliner.BZPopMax(ctx Context, timeout time.Duration, keys ...string) *redis.ZWithKeyCmd func github.com/redis/go-redis/v9.Pipeliner.BZPopMin(ctx Context, timeout time.Duration, keys ...string) *redis.ZWithKeyCmd func github.com/redis/go-redis/v9.Pipeliner.ClientGetName(ctx Context) *redis.StringCmd func github.com/redis/go-redis/v9.Pipeliner.ClientID(ctx Context) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.ClientKill(ctx Context, ipPort string) *redis.StatusCmd func github.com/redis/go-redis/v9.Pipeliner.ClientKillByFilter(ctx Context, keys ...string) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.ClientList(ctx Context) *redis.StringCmd func github.com/redis/go-redis/v9.Pipeliner.ClientPause(ctx Context, dur time.Duration) *redis.BoolCmd func github.com/redis/go-redis/v9.Pipeliner.ClientSetName(ctx Context, name string) *redis.BoolCmd func github.com/redis/go-redis/v9.Pipeliner.ClientUnblock(ctx Context, id int64) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.ClientUnblockWithError(ctx Context, id int64) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.ClientUnpause(ctx Context) *redis.BoolCmd func github.com/redis/go-redis/v9.Pipeliner.ClusterAddSlots(ctx Context, slots ...int) *redis.StatusCmd func github.com/redis/go-redis/v9.Pipeliner.ClusterAddSlotsRange(ctx Context, min, max int) *redis.StatusCmd func github.com/redis/go-redis/v9.Pipeliner.ClusterCountFailureReports(ctx Context, nodeID string) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.ClusterCountKeysInSlot(ctx Context, slot int) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.ClusterDelSlots(ctx Context, slots ...int) *redis.StatusCmd func github.com/redis/go-redis/v9.Pipeliner.ClusterDelSlotsRange(ctx Context, min, max int) *redis.StatusCmd func github.com/redis/go-redis/v9.Pipeliner.ClusterFailover(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.Pipeliner.ClusterForget(ctx Context, nodeID string) *redis.StatusCmd func github.com/redis/go-redis/v9.Pipeliner.ClusterGetKeysInSlot(ctx Context, slot int, count int) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Pipeliner.ClusterInfo(ctx Context) *redis.StringCmd func github.com/redis/go-redis/v9.Pipeliner.ClusterKeySlot(ctx Context, key string) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.ClusterLinks(ctx Context) *redis.ClusterLinksCmd func github.com/redis/go-redis/v9.Pipeliner.ClusterMeet(ctx Context, host, port string) *redis.StatusCmd func github.com/redis/go-redis/v9.Pipeliner.ClusterNodes(ctx Context) *redis.StringCmd func github.com/redis/go-redis/v9.Pipeliner.ClusterReplicate(ctx Context, nodeID string) *redis.StatusCmd func github.com/redis/go-redis/v9.Pipeliner.ClusterResetHard(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.Pipeliner.ClusterResetSoft(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.Pipeliner.ClusterSaveConfig(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.Pipeliner.ClusterShards(ctx Context) *redis.ClusterShardsCmd func github.com/redis/go-redis/v9.Pipeliner.ClusterSlaves(ctx Context, nodeID string) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Pipeliner.ClusterSlots(ctx Context) *redis.ClusterSlotsCmd func github.com/redis/go-redis/v9.Pipeliner.Command(ctx Context) *redis.CommandsInfoCmd func github.com/redis/go-redis/v9.Pipeliner.CommandGetKeys(ctx Context, commands ...interface{}) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Pipeliner.CommandGetKeysAndFlags(ctx Context, commands ...interface{}) *redis.KeyFlagsCmd func github.com/redis/go-redis/v9.Pipeliner.CommandList(ctx Context, filter *redis.FilterBy) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Pipeliner.ConfigGet(ctx Context, parameter string) *redis.MapStringStringCmd func github.com/redis/go-redis/v9.Pipeliner.ConfigResetStat(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.Pipeliner.ConfigRewrite(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.Pipeliner.ConfigSet(ctx Context, parameter, value string) *redis.StatusCmd func github.com/redis/go-redis/v9.Pipeliner.Copy(ctx Context, sourceKey string, destKey string, db int, replace bool) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.DBSize(ctx Context) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.DebugObject(ctx Context, key string) *redis.StringCmd func github.com/redis/go-redis/v9.Pipeliner.Decr(ctx Context, key string) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.DecrBy(ctx Context, key string, decrement int64) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.Del(ctx Context, keys ...string) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.Do(ctx Context, args ...interface{}) *redis.Cmd func github.com/redis/go-redis/v9.Pipeliner.Dump(ctx Context, key string) *redis.StringCmd func github.com/redis/go-redis/v9.Pipeliner.Echo(ctx Context, message interface{}) *redis.StringCmd func github.com/redis/go-redis/v9.Pipeliner.Eval(ctx Context, script string, keys []string, args ...interface{}) *redis.Cmd func github.com/redis/go-redis/v9.Pipeliner.EvalRO(ctx Context, script string, keys []string, args ...interface{}) *redis.Cmd func github.com/redis/go-redis/v9.Pipeliner.EvalSha(ctx Context, sha1 string, keys []string, args ...interface{}) *redis.Cmd func github.com/redis/go-redis/v9.Pipeliner.EvalShaRO(ctx Context, sha1 string, keys []string, args ...interface{}) *redis.Cmd func github.com/redis/go-redis/v9.Pipeliner.Exec(ctx Context) ([]redis.Cmder, error) func github.com/redis/go-redis/v9.Pipeliner.Exists(ctx Context, keys ...string) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.Expire(ctx Context, key string, expiration time.Duration) *redis.BoolCmd func github.com/redis/go-redis/v9.Pipeliner.ExpireAt(ctx Context, key string, tm time.Time) *redis.BoolCmd func github.com/redis/go-redis/v9.Pipeliner.ExpireGT(ctx Context, key string, expiration time.Duration) *redis.BoolCmd func github.com/redis/go-redis/v9.Pipeliner.ExpireLT(ctx Context, key string, expiration time.Duration) *redis.BoolCmd func github.com/redis/go-redis/v9.Pipeliner.ExpireNX(ctx Context, key string, expiration time.Duration) *redis.BoolCmd func github.com/redis/go-redis/v9.Pipeliner.ExpireTime(ctx Context, key string) *redis.DurationCmd func github.com/redis/go-redis/v9.Pipeliner.ExpireXX(ctx Context, key string, expiration time.Duration) *redis.BoolCmd func github.com/redis/go-redis/v9.Pipeliner.FCall(ctx Context, function string, keys []string, args ...interface{}) *redis.Cmd func github.com/redis/go-redis/v9.Pipeliner.FCallRo(ctx Context, function string, keys []string, args ...interface{}) *redis.Cmd func github.com/redis/go-redis/v9.Pipeliner.FlushAll(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.Pipeliner.FlushAllAsync(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.Pipeliner.FlushDB(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.Pipeliner.FlushDBAsync(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.Pipeliner.FunctionDelete(ctx Context, libName string) *redis.StringCmd func github.com/redis/go-redis/v9.Pipeliner.FunctionDump(ctx Context) *redis.StringCmd func github.com/redis/go-redis/v9.Pipeliner.FunctionFlush(ctx Context) *redis.StringCmd func github.com/redis/go-redis/v9.Pipeliner.FunctionFlushAsync(ctx Context) *redis.StringCmd func github.com/redis/go-redis/v9.Pipeliner.FunctionKill(ctx Context) *redis.StringCmd func github.com/redis/go-redis/v9.Pipeliner.FunctionList(ctx Context, q redis.FunctionListQuery) *redis.FunctionListCmd func github.com/redis/go-redis/v9.Pipeliner.FunctionLoad(ctx Context, code string) *redis.StringCmd func github.com/redis/go-redis/v9.Pipeliner.FunctionLoadReplace(ctx Context, code string) *redis.StringCmd func github.com/redis/go-redis/v9.Pipeliner.FunctionRestore(ctx Context, libDump string) *redis.StringCmd func github.com/redis/go-redis/v9.Pipeliner.FunctionStats(ctx Context) *redis.FunctionStatsCmd func github.com/redis/go-redis/v9.Pipeliner.GeoAdd(ctx Context, key string, geoLocation ...*redis.GeoLocation) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.GeoDist(ctx Context, key string, member1, member2, unit string) *redis.FloatCmd func github.com/redis/go-redis/v9.Pipeliner.GeoHash(ctx Context, key string, members ...string) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Pipeliner.GeoPos(ctx Context, key string, members ...string) *redis.GeoPosCmd func github.com/redis/go-redis/v9.Pipeliner.GeoRadius(ctx Context, key string, longitude, latitude float64, query *redis.GeoRadiusQuery) *redis.GeoLocationCmd func github.com/redis/go-redis/v9.Pipeliner.GeoRadiusByMember(ctx Context, key, member string, query *redis.GeoRadiusQuery) *redis.GeoLocationCmd func github.com/redis/go-redis/v9.Pipeliner.GeoRadiusByMemberStore(ctx Context, key, member string, query *redis.GeoRadiusQuery) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.GeoRadiusStore(ctx Context, key string, longitude, latitude float64, query *redis.GeoRadiusQuery) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.GeoSearch(ctx Context, key string, q *redis.GeoSearchQuery) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Pipeliner.GeoSearchLocation(ctx Context, key string, q *redis.GeoSearchLocationQuery) *redis.GeoSearchLocationCmd func github.com/redis/go-redis/v9.Pipeliner.GeoSearchStore(ctx Context, key, store string, q *redis.GeoSearchStoreQuery) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.Get(ctx Context, key string) *redis.StringCmd func github.com/redis/go-redis/v9.Pipeliner.GetBit(ctx Context, key string, offset int64) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.GetDel(ctx Context, key string) *redis.StringCmd func github.com/redis/go-redis/v9.Pipeliner.GetEx(ctx Context, key string, expiration time.Duration) *redis.StringCmd func github.com/redis/go-redis/v9.Pipeliner.GetRange(ctx Context, key string, start, end int64) *redis.StringCmd func github.com/redis/go-redis/v9.Pipeliner.GetSet(ctx Context, key string, value interface{}) *redis.StringCmd func github.com/redis/go-redis/v9.Pipeliner.HDel(ctx Context, key string, fields ...string) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.Hello(ctx Context, ver int, username, password, clientName string) *redis.MapStringInterfaceCmd func github.com/redis/go-redis/v9.Pipeliner.HExists(ctx Context, key, field string) *redis.BoolCmd func github.com/redis/go-redis/v9.Pipeliner.HGet(ctx Context, key, field string) *redis.StringCmd func github.com/redis/go-redis/v9.Pipeliner.HGetAll(ctx Context, key string) *redis.MapStringStringCmd func github.com/redis/go-redis/v9.Pipeliner.HIncrBy(ctx Context, key, field string, incr int64) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.HIncrByFloat(ctx Context, key, field string, incr float64) *redis.FloatCmd func github.com/redis/go-redis/v9.Pipeliner.HKeys(ctx Context, key string) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Pipeliner.HLen(ctx Context, key string) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.HMGet(ctx Context, key string, fields ...string) *redis.SliceCmd func github.com/redis/go-redis/v9.Pipeliner.HMSet(ctx Context, key string, values ...interface{}) *redis.BoolCmd func github.com/redis/go-redis/v9.Pipeliner.HRandField(ctx Context, key string, count int) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Pipeliner.HRandFieldWithValues(ctx Context, key string, count int) *redis.KeyValueSliceCmd func github.com/redis/go-redis/v9.Pipeliner.HScan(ctx Context, key string, cursor uint64, match string, count int64) *redis.ScanCmd func github.com/redis/go-redis/v9.Pipeliner.HSet(ctx Context, key string, values ...interface{}) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.HSetNX(ctx Context, key, field string, value interface{}) *redis.BoolCmd func github.com/redis/go-redis/v9.Pipeliner.HVals(ctx Context, key string) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Pipeliner.Incr(ctx Context, key string) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.IncrBy(ctx Context, key string, value int64) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.IncrByFloat(ctx Context, key string, value float64) *redis.FloatCmd func github.com/redis/go-redis/v9.Pipeliner.Info(ctx Context, section ...string) *redis.StringCmd func github.com/redis/go-redis/v9.Pipeliner.Keys(ctx Context, pattern string) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Pipeliner.LastSave(ctx Context) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.LCS(ctx Context, q *redis.LCSQuery) *redis.LCSCmd func github.com/redis/go-redis/v9.Pipeliner.LIndex(ctx Context, key string, index int64) *redis.StringCmd func github.com/redis/go-redis/v9.Pipeliner.LInsert(ctx Context, key, op string, pivot, value interface{}) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.LInsertAfter(ctx Context, key string, pivot, value interface{}) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.LInsertBefore(ctx Context, key string, pivot, value interface{}) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.LLen(ctx Context, key string) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.LMove(ctx Context, source, destination, srcpos, destpos string) *redis.StringCmd func github.com/redis/go-redis/v9.Pipeliner.LMPop(ctx Context, direction string, count int64, keys ...string) *redis.KeyValuesCmd func github.com/redis/go-redis/v9.Pipeliner.LPop(ctx Context, key string) *redis.StringCmd func github.com/redis/go-redis/v9.Pipeliner.LPopCount(ctx Context, key string, count int) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Pipeliner.LPos(ctx Context, key string, value string, args redis.LPosArgs) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.LPosCount(ctx Context, key string, value string, count int64, args redis.LPosArgs) *redis.IntSliceCmd func github.com/redis/go-redis/v9.Pipeliner.LPush(ctx Context, key string, values ...interface{}) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.LPushX(ctx Context, key string, values ...interface{}) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.LRange(ctx Context, key string, start, stop int64) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Pipeliner.LRem(ctx Context, key string, count int64, value interface{}) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.LSet(ctx Context, key string, index int64, value interface{}) *redis.StatusCmd func github.com/redis/go-redis/v9.Pipeliner.LTrim(ctx Context, key string, start, stop int64) *redis.StatusCmd func github.com/redis/go-redis/v9.Pipeliner.MemoryUsage(ctx Context, key string, samples ...int) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.MGet(ctx Context, keys ...string) *redis.SliceCmd func github.com/redis/go-redis/v9.Pipeliner.Migrate(ctx Context, host, port, key string, db int, timeout time.Duration) *redis.StatusCmd func github.com/redis/go-redis/v9.Pipeliner.Move(ctx Context, key string, db int) *redis.BoolCmd func github.com/redis/go-redis/v9.Pipeliner.MSet(ctx Context, values ...interface{}) *redis.StatusCmd func github.com/redis/go-redis/v9.Pipeliner.MSetNX(ctx Context, values ...interface{}) *redis.BoolCmd func github.com/redis/go-redis/v9.Pipeliner.ObjectEncoding(ctx Context, key string) *redis.StringCmd func github.com/redis/go-redis/v9.Pipeliner.ObjectIdleTime(ctx Context, key string) *redis.DurationCmd func github.com/redis/go-redis/v9.Pipeliner.ObjectRefCount(ctx Context, key string) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.Persist(ctx Context, key string) *redis.BoolCmd func github.com/redis/go-redis/v9.Pipeliner.PExpire(ctx Context, key string, expiration time.Duration) *redis.BoolCmd func github.com/redis/go-redis/v9.Pipeliner.PExpireAt(ctx Context, key string, tm time.Time) *redis.BoolCmd func github.com/redis/go-redis/v9.Pipeliner.PExpireTime(ctx Context, key string) *redis.DurationCmd func github.com/redis/go-redis/v9.Pipeliner.PFAdd(ctx Context, key string, els ...interface{}) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.PFCount(ctx Context, keys ...string) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.PFMerge(ctx Context, dest string, keys ...string) *redis.StatusCmd func github.com/redis/go-redis/v9.Pipeliner.Ping(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.Pipeliner.Pipelined(ctx Context, fn func(redis.Pipeliner) error) ([]redis.Cmder, error) func github.com/redis/go-redis/v9.Pipeliner.Process(ctx Context, cmd redis.Cmder) error func github.com/redis/go-redis/v9.Pipeliner.PTTL(ctx Context, key string) *redis.DurationCmd func github.com/redis/go-redis/v9.Pipeliner.Publish(ctx Context, channel string, message interface{}) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.PubSubChannels(ctx Context, pattern string) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Pipeliner.PubSubNumPat(ctx Context) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.PubSubNumSub(ctx Context, channels ...string) *redis.MapStringIntCmd func github.com/redis/go-redis/v9.Pipeliner.PubSubShardChannels(ctx Context, pattern string) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Pipeliner.PubSubShardNumSub(ctx Context, channels ...string) *redis.MapStringIntCmd func github.com/redis/go-redis/v9.Pipeliner.Quit(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.Pipeliner.RandomKey(ctx Context) *redis.StringCmd func github.com/redis/go-redis/v9.Pipeliner.ReadOnly(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.Pipeliner.ReadWrite(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.Pipeliner.Rename(ctx Context, key, newkey string) *redis.StatusCmd func github.com/redis/go-redis/v9.Pipeliner.RenameNX(ctx Context, key, newkey string) *redis.BoolCmd func github.com/redis/go-redis/v9.Pipeliner.Restore(ctx Context, key string, ttl time.Duration, value string) *redis.StatusCmd func github.com/redis/go-redis/v9.Pipeliner.RestoreReplace(ctx Context, key string, ttl time.Duration, value string) *redis.StatusCmd func github.com/redis/go-redis/v9.Pipeliner.RPop(ctx Context, key string) *redis.StringCmd func github.com/redis/go-redis/v9.Pipeliner.RPopCount(ctx Context, key string, count int) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Pipeliner.RPopLPush(ctx Context, source, destination string) *redis.StringCmd func github.com/redis/go-redis/v9.Pipeliner.RPush(ctx Context, key string, values ...interface{}) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.RPushX(ctx Context, key string, values ...interface{}) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.SAdd(ctx Context, key string, members ...interface{}) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.Save(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.Pipeliner.Scan(ctx Context, cursor uint64, match string, count int64) *redis.ScanCmd func github.com/redis/go-redis/v9.Pipeliner.ScanType(ctx Context, cursor uint64, match string, count int64, keyType string) *redis.ScanCmd func github.com/redis/go-redis/v9.Pipeliner.SCard(ctx Context, key string) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.ScriptExists(ctx Context, hashes ...string) *redis.BoolSliceCmd func github.com/redis/go-redis/v9.Pipeliner.ScriptFlush(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.Pipeliner.ScriptKill(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.Pipeliner.ScriptLoad(ctx Context, script string) *redis.StringCmd func github.com/redis/go-redis/v9.Pipeliner.SDiff(ctx Context, keys ...string) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Pipeliner.SDiffStore(ctx Context, destination string, keys ...string) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.Select(ctx Context, index int) *redis.StatusCmd func github.com/redis/go-redis/v9.Pipeliner.Set(ctx Context, key string, value interface{}, expiration time.Duration) *redis.StatusCmd func github.com/redis/go-redis/v9.Pipeliner.SetArgs(ctx Context, key string, value interface{}, a redis.SetArgs) *redis.StatusCmd func github.com/redis/go-redis/v9.Pipeliner.SetBit(ctx Context, key string, offset int64, value int) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.SetEx(ctx Context, key string, value interface{}, expiration time.Duration) *redis.StatusCmd func github.com/redis/go-redis/v9.Pipeliner.SetNX(ctx Context, key string, value interface{}, expiration time.Duration) *redis.BoolCmd func github.com/redis/go-redis/v9.Pipeliner.SetRange(ctx Context, key string, offset int64, value string) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.SetXX(ctx Context, key string, value interface{}, expiration time.Duration) *redis.BoolCmd func github.com/redis/go-redis/v9.Pipeliner.Shutdown(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.Pipeliner.ShutdownNoSave(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.Pipeliner.ShutdownSave(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.Pipeliner.SInter(ctx Context, keys ...string) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Pipeliner.SInterCard(ctx Context, limit int64, keys ...string) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.SInterStore(ctx Context, destination string, keys ...string) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.SIsMember(ctx Context, key string, member interface{}) *redis.BoolCmd func github.com/redis/go-redis/v9.Pipeliner.SlaveOf(ctx Context, host, port string) *redis.StatusCmd func github.com/redis/go-redis/v9.Pipeliner.SlowLogGet(ctx Context, num int64) *redis.SlowLogCmd func github.com/redis/go-redis/v9.Pipeliner.SMembers(ctx Context, key string) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Pipeliner.SMembersMap(ctx Context, key string) *redis.StringStructMapCmd func github.com/redis/go-redis/v9.Pipeliner.SMIsMember(ctx Context, key string, members ...interface{}) *redis.BoolSliceCmd func github.com/redis/go-redis/v9.Pipeliner.SMove(ctx Context, source, destination string, member interface{}) *redis.BoolCmd func github.com/redis/go-redis/v9.Pipeliner.Sort(ctx Context, key string, sort *redis.Sort) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Pipeliner.SortInterfaces(ctx Context, key string, sort *redis.Sort) *redis.SliceCmd func github.com/redis/go-redis/v9.Pipeliner.SortRO(ctx Context, key string, sort *redis.Sort) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Pipeliner.SortStore(ctx Context, key, store string, sort *redis.Sort) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.SPop(ctx Context, key string) *redis.StringCmd func github.com/redis/go-redis/v9.Pipeliner.SPopN(ctx Context, key string, count int64) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Pipeliner.SPublish(ctx Context, channel string, message interface{}) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.SRandMember(ctx Context, key string) *redis.StringCmd func github.com/redis/go-redis/v9.Pipeliner.SRandMemberN(ctx Context, key string, count int64) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Pipeliner.SRem(ctx Context, key string, members ...interface{}) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.SScan(ctx Context, key string, cursor uint64, match string, count int64) *redis.ScanCmd func github.com/redis/go-redis/v9.Pipeliner.StrLen(ctx Context, key string) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.SUnion(ctx Context, keys ...string) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Pipeliner.SUnionStore(ctx Context, destination string, keys ...string) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.SwapDB(ctx Context, index1, index2 int) *redis.StatusCmd func github.com/redis/go-redis/v9.Pipeliner.Time(ctx Context) *redis.TimeCmd func github.com/redis/go-redis/v9.Pipeliner.Touch(ctx Context, keys ...string) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.TTL(ctx Context, key string) *redis.DurationCmd func github.com/redis/go-redis/v9.Pipeliner.TxPipelined(ctx Context, fn func(redis.Pipeliner) error) ([]redis.Cmder, error) func github.com/redis/go-redis/v9.Pipeliner.Type(ctx Context, key string) *redis.StatusCmd func github.com/redis/go-redis/v9.Pipeliner.Unlink(ctx Context, keys ...string) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.XAck(ctx Context, stream, group string, ids ...string) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.XAdd(ctx Context, a *redis.XAddArgs) *redis.StringCmd func github.com/redis/go-redis/v9.Pipeliner.XAutoClaim(ctx Context, a *redis.XAutoClaimArgs) *redis.XAutoClaimCmd func github.com/redis/go-redis/v9.Pipeliner.XAutoClaimJustID(ctx Context, a *redis.XAutoClaimArgs) *redis.XAutoClaimJustIDCmd func github.com/redis/go-redis/v9.Pipeliner.XClaim(ctx Context, a *redis.XClaimArgs) *redis.XMessageSliceCmd func github.com/redis/go-redis/v9.Pipeliner.XClaimJustID(ctx Context, a *redis.XClaimArgs) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Pipeliner.XDel(ctx Context, stream string, ids ...string) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.XGroupCreate(ctx Context, stream, group, start string) *redis.StatusCmd func github.com/redis/go-redis/v9.Pipeliner.XGroupCreateConsumer(ctx Context, stream, group, consumer string) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.XGroupCreateMkStream(ctx Context, stream, group, start string) *redis.StatusCmd func github.com/redis/go-redis/v9.Pipeliner.XGroupDelConsumer(ctx Context, stream, group, consumer string) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.XGroupDestroy(ctx Context, stream, group string) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.XGroupSetID(ctx Context, stream, group, start string) *redis.StatusCmd func github.com/redis/go-redis/v9.Pipeliner.XInfoConsumers(ctx Context, key string, group string) *redis.XInfoConsumersCmd func github.com/redis/go-redis/v9.Pipeliner.XInfoGroups(ctx Context, key string) *redis.XInfoGroupsCmd func github.com/redis/go-redis/v9.Pipeliner.XInfoStream(ctx Context, key string) *redis.XInfoStreamCmd func github.com/redis/go-redis/v9.Pipeliner.XInfoStreamFull(ctx Context, key string, count int) *redis.XInfoStreamFullCmd func github.com/redis/go-redis/v9.Pipeliner.XLen(ctx Context, stream string) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.XPending(ctx Context, stream, group string) *redis.XPendingCmd func github.com/redis/go-redis/v9.Pipeliner.XPendingExt(ctx Context, a *redis.XPendingExtArgs) *redis.XPendingExtCmd func github.com/redis/go-redis/v9.Pipeliner.XRange(ctx Context, stream, start, stop string) *redis.XMessageSliceCmd func github.com/redis/go-redis/v9.Pipeliner.XRangeN(ctx Context, stream, start, stop string, count int64) *redis.XMessageSliceCmd func github.com/redis/go-redis/v9.Pipeliner.XRead(ctx Context, a *redis.XReadArgs) *redis.XStreamSliceCmd func github.com/redis/go-redis/v9.Pipeliner.XReadGroup(ctx Context, a *redis.XReadGroupArgs) *redis.XStreamSliceCmd func github.com/redis/go-redis/v9.Pipeliner.XReadStreams(ctx Context, streams ...string) *redis.XStreamSliceCmd func github.com/redis/go-redis/v9.Pipeliner.XRevRange(ctx Context, stream string, start, stop string) *redis.XMessageSliceCmd func github.com/redis/go-redis/v9.Pipeliner.XRevRangeN(ctx Context, stream string, start, stop string, count int64) *redis.XMessageSliceCmd func github.com/redis/go-redis/v9.Pipeliner.XTrimMaxLen(ctx Context, key string, maxLen int64) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.XTrimMaxLenApprox(ctx Context, key string, maxLen, limit int64) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.XTrimMinID(ctx Context, key string, minID string) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.XTrimMinIDApprox(ctx Context, key string, minID string, limit int64) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.ZAdd(ctx Context, key string, members ...redis.Z) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.ZAddArgs(ctx Context, key string, args redis.ZAddArgs) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.ZAddArgsIncr(ctx Context, key string, args redis.ZAddArgs) *redis.FloatCmd func github.com/redis/go-redis/v9.Pipeliner.ZAddGT(ctx Context, key string, members ...redis.Z) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.ZAddLT(ctx Context, key string, members ...redis.Z) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.ZAddNX(ctx Context, key string, members ...redis.Z) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.ZAddXX(ctx Context, key string, members ...redis.Z) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.ZCard(ctx Context, key string) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.ZCount(ctx Context, key, min, max string) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.ZDiff(ctx Context, keys ...string) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Pipeliner.ZDiffStore(ctx Context, destination string, keys ...string) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.ZDiffWithScores(ctx Context, keys ...string) *redis.ZSliceCmd func github.com/redis/go-redis/v9.Pipeliner.ZIncrBy(ctx Context, key string, increment float64, member string) *redis.FloatCmd func github.com/redis/go-redis/v9.Pipeliner.ZInter(ctx Context, store *redis.ZStore) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Pipeliner.ZInterCard(ctx Context, limit int64, keys ...string) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.ZInterStore(ctx Context, destination string, store *redis.ZStore) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.ZInterWithScores(ctx Context, store *redis.ZStore) *redis.ZSliceCmd func github.com/redis/go-redis/v9.Pipeliner.ZLexCount(ctx Context, key, min, max string) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.ZMPop(ctx Context, order string, count int64, keys ...string) *redis.ZSliceWithKeyCmd func github.com/redis/go-redis/v9.Pipeliner.ZMScore(ctx Context, key string, members ...string) *redis.FloatSliceCmd func github.com/redis/go-redis/v9.Pipeliner.ZPopMax(ctx Context, key string, count ...int64) *redis.ZSliceCmd func github.com/redis/go-redis/v9.Pipeliner.ZPopMin(ctx Context, key string, count ...int64) *redis.ZSliceCmd func github.com/redis/go-redis/v9.Pipeliner.ZRandMember(ctx Context, key string, count int) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Pipeliner.ZRandMemberWithScores(ctx Context, key string, count int) *redis.ZSliceCmd func github.com/redis/go-redis/v9.Pipeliner.ZRange(ctx Context, key string, start, stop int64) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Pipeliner.ZRangeArgs(ctx Context, z redis.ZRangeArgs) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Pipeliner.ZRangeArgsWithScores(ctx Context, z redis.ZRangeArgs) *redis.ZSliceCmd func github.com/redis/go-redis/v9.Pipeliner.ZRangeByLex(ctx Context, key string, opt *redis.ZRangeBy) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Pipeliner.ZRangeByScore(ctx Context, key string, opt *redis.ZRangeBy) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Pipeliner.ZRangeByScoreWithScores(ctx Context, key string, opt *redis.ZRangeBy) *redis.ZSliceCmd func github.com/redis/go-redis/v9.Pipeliner.ZRangeStore(ctx Context, dst string, z redis.ZRangeArgs) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.ZRangeWithScores(ctx Context, key string, start, stop int64) *redis.ZSliceCmd func github.com/redis/go-redis/v9.Pipeliner.ZRank(ctx Context, key, member string) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.ZRem(ctx Context, key string, members ...interface{}) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.ZRemRangeByLex(ctx Context, key, min, max string) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.ZRemRangeByRank(ctx Context, key string, start, stop int64) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.ZRemRangeByScore(ctx Context, key, min, max string) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.ZRevRange(ctx Context, key string, start, stop int64) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Pipeliner.ZRevRangeByLex(ctx Context, key string, opt *redis.ZRangeBy) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Pipeliner.ZRevRangeByScore(ctx Context, key string, opt *redis.ZRangeBy) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Pipeliner.ZRevRangeByScoreWithScores(ctx Context, key string, opt *redis.ZRangeBy) *redis.ZSliceCmd func github.com/redis/go-redis/v9.Pipeliner.ZRevRangeWithScores(ctx Context, key string, start, stop int64) *redis.ZSliceCmd func github.com/redis/go-redis/v9.Pipeliner.ZRevRank(ctx Context, key, member string) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.ZScan(ctx Context, key string, cursor uint64, match string, count int64) *redis.ScanCmd func github.com/redis/go-redis/v9.Pipeliner.ZScore(ctx Context, key, member string) *redis.FloatCmd func github.com/redis/go-redis/v9.Pipeliner.ZUnion(ctx Context, store redis.ZStore) *redis.StringSliceCmd func github.com/redis/go-redis/v9.Pipeliner.ZUnionStore(ctx Context, dest string, store *redis.ZStore) *redis.IntCmd func github.com/redis/go-redis/v9.Pipeliner.ZUnionWithScores(ctx Context, store redis.ZStore) *redis.ZSliceCmd func github.com/redis/go-redis/v9.(*PubSub).Ping(ctx Context, payload ...string) error func github.com/redis/go-redis/v9.(*PubSub).PSubscribe(ctx Context, patterns ...string) error func github.com/redis/go-redis/v9.(*PubSub).PUnsubscribe(ctx Context, patterns ...string) error func github.com/redis/go-redis/v9.(*PubSub).Receive(ctx Context) (interface{}, error) func github.com/redis/go-redis/v9.(*PubSub).ReceiveMessage(ctx Context) (*redis.Message, error) func github.com/redis/go-redis/v9.(*PubSub).ReceiveTimeout(ctx Context, timeout time.Duration) (interface{}, error) func github.com/redis/go-redis/v9.(*PubSub).SSubscribe(ctx Context, channels ...string) error func github.com/redis/go-redis/v9.(*PubSub).Subscribe(ctx Context, channels ...string) error func github.com/redis/go-redis/v9.(*PubSub).SUnsubscribe(ctx Context, channels ...string) error func github.com/redis/go-redis/v9.(*PubSub).Unsubscribe(ctx Context, channels ...string) error func github.com/redis/go-redis/v9.(*Ring).Do(ctx Context, args ...interface{}) *redis.Cmd func github.com/redis/go-redis/v9.(*Ring).ForEachShard(ctx Context, fn func(ctx Context, client *redis.Client) error) error func github.com/redis/go-redis/v9.(*Ring).Pipelined(ctx Context, fn func(redis.Pipeliner) error) ([]redis.Cmder, error) func github.com/redis/go-redis/v9.(*Ring).Process(ctx Context, cmd redis.Cmder) error func github.com/redis/go-redis/v9.(*Ring).PSubscribe(ctx Context, channels ...string) *redis.PubSub func github.com/redis/go-redis/v9.(*Ring).SSubscribe(ctx Context, channels ...string) *redis.PubSub func github.com/redis/go-redis/v9.(*Ring).Subscribe(ctx Context, channels ...string) *redis.PubSub func github.com/redis/go-redis/v9.(*Ring).TxPipelined(ctx Context, fn func(redis.Pipeliner) error) ([]redis.Cmder, error) func github.com/redis/go-redis/v9.(*Ring).Watch(ctx Context, fn func(*redis.Tx) error, keys ...string) error func github.com/redis/go-redis/v9.(*ScanIterator).Next(ctx Context) bool func github.com/redis/go-redis/v9.(*Script).Eval(ctx Context, c redis.Scripter, keys []string, args ...interface{}) *redis.Cmd func github.com/redis/go-redis/v9.(*Script).EvalRO(ctx Context, c redis.Scripter, keys []string, args ...interface{}) *redis.Cmd func github.com/redis/go-redis/v9.(*Script).EvalSha(ctx Context, c redis.Scripter, keys []string, args ...interface{}) *redis.Cmd func github.com/redis/go-redis/v9.(*Script).EvalShaRO(ctx Context, c redis.Scripter, keys []string, args ...interface{}) *redis.Cmd func github.com/redis/go-redis/v9.(*Script).Exists(ctx Context, c redis.Scripter) *redis.BoolSliceCmd func github.com/redis/go-redis/v9.(*Script).Load(ctx Context, c redis.Scripter) *redis.StringCmd func github.com/redis/go-redis/v9.(*Script).Run(ctx Context, c redis.Scripter, keys []string, args ...interface{}) *redis.Cmd func github.com/redis/go-redis/v9.(*Script).RunRO(ctx Context, c redis.Scripter, keys []string, args ...interface{}) *redis.Cmd func github.com/redis/go-redis/v9.Scripter.Eval(ctx Context, script string, keys []string, args ...interface{}) *redis.Cmd func github.com/redis/go-redis/v9.Scripter.EvalRO(ctx Context, script string, keys []string, args ...interface{}) *redis.Cmd func github.com/redis/go-redis/v9.Scripter.EvalSha(ctx Context, sha1 string, keys []string, args ...interface{}) *redis.Cmd func github.com/redis/go-redis/v9.Scripter.EvalShaRO(ctx Context, sha1 string, keys []string, args ...interface{}) *redis.Cmd func github.com/redis/go-redis/v9.Scripter.ScriptExists(ctx Context, hashes ...string) *redis.BoolSliceCmd func github.com/redis/go-redis/v9.Scripter.ScriptLoad(ctx Context, script string) *redis.StringCmd func github.com/redis/go-redis/v9.(*SentinelClient).CkQuorum(ctx Context, name string) *redis.StringCmd func github.com/redis/go-redis/v9.(*SentinelClient).Failover(ctx Context, name string) *redis.StatusCmd func github.com/redis/go-redis/v9.(*SentinelClient).FlushConfig(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.(*SentinelClient).GetMasterAddrByName(ctx Context, name string) *redis.StringSliceCmd func github.com/redis/go-redis/v9.(*SentinelClient).Master(ctx Context, name string) *redis.MapStringStringCmd func github.com/redis/go-redis/v9.(*SentinelClient).Masters(ctx Context) *redis.SliceCmd func github.com/redis/go-redis/v9.(*SentinelClient).Monitor(ctx Context, name, ip, port, quorum string) *redis.StringCmd func github.com/redis/go-redis/v9.(*SentinelClient).Ping(ctx Context) *redis.StringCmd func github.com/redis/go-redis/v9.(*SentinelClient).Process(ctx Context, cmd redis.Cmder) error func github.com/redis/go-redis/v9.(*SentinelClient).PSubscribe(ctx Context, channels ...string) *redis.PubSub func github.com/redis/go-redis/v9.(*SentinelClient).Remove(ctx Context, name string) *redis.StringCmd func github.com/redis/go-redis/v9.(*SentinelClient).Replicas(ctx Context, name string) *redis.MapStringStringSliceCmd func github.com/redis/go-redis/v9.(*SentinelClient).Reset(ctx Context, pattern string) *redis.IntCmd func github.com/redis/go-redis/v9.(*SentinelClient).Sentinels(ctx Context, name string) *redis.MapStringStringSliceCmd func github.com/redis/go-redis/v9.(*SentinelClient).Set(ctx Context, name, option, value string) *redis.StringCmd func github.com/redis/go-redis/v9.(*SentinelClient).Subscribe(ctx Context, channels ...string) *redis.PubSub func github.com/redis/go-redis/v9.StatefulCmdable.ACLDryRun(ctx Context, username string, command ...interface{}) *redis.StringCmd func github.com/redis/go-redis/v9.StatefulCmdable.Append(ctx Context, key, value string) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.Auth(ctx Context, password string) *redis.StatusCmd func github.com/redis/go-redis/v9.StatefulCmdable.AuthACL(ctx Context, username, password string) *redis.StatusCmd func github.com/redis/go-redis/v9.StatefulCmdable.BgRewriteAOF(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.StatefulCmdable.BgSave(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.StatefulCmdable.BitCount(ctx Context, key string, bitCount *redis.BitCount) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.BitField(ctx Context, key string, args ...interface{}) *redis.IntSliceCmd func github.com/redis/go-redis/v9.StatefulCmdable.BitOpAnd(ctx Context, destKey string, keys ...string) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.BitOpNot(ctx Context, destKey string, key string) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.BitOpOr(ctx Context, destKey string, keys ...string) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.BitOpXor(ctx Context, destKey string, keys ...string) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.BitPos(ctx Context, key string, bit int64, pos ...int64) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.BitPosSpan(ctx Context, key string, bit int8, start, end int64, span string) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.BLMove(ctx Context, source, destination, srcpos, destpos string, timeout time.Duration) *redis.StringCmd func github.com/redis/go-redis/v9.StatefulCmdable.BLMPop(ctx Context, timeout time.Duration, direction string, count int64, keys ...string) *redis.KeyValuesCmd func github.com/redis/go-redis/v9.StatefulCmdable.BLPop(ctx Context, timeout time.Duration, keys ...string) *redis.StringSliceCmd func github.com/redis/go-redis/v9.StatefulCmdable.BRPop(ctx Context, timeout time.Duration, keys ...string) *redis.StringSliceCmd func github.com/redis/go-redis/v9.StatefulCmdable.BRPopLPush(ctx Context, source, destination string, timeout time.Duration) *redis.StringCmd func github.com/redis/go-redis/v9.StatefulCmdable.BZMPop(ctx Context, timeout time.Duration, order string, count int64, keys ...string) *redis.ZSliceWithKeyCmd func github.com/redis/go-redis/v9.StatefulCmdable.BZPopMax(ctx Context, timeout time.Duration, keys ...string) *redis.ZWithKeyCmd func github.com/redis/go-redis/v9.StatefulCmdable.BZPopMin(ctx Context, timeout time.Duration, keys ...string) *redis.ZWithKeyCmd func github.com/redis/go-redis/v9.StatefulCmdable.ClientGetName(ctx Context) *redis.StringCmd func github.com/redis/go-redis/v9.StatefulCmdable.ClientID(ctx Context) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.ClientKill(ctx Context, ipPort string) *redis.StatusCmd func github.com/redis/go-redis/v9.StatefulCmdable.ClientKillByFilter(ctx Context, keys ...string) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.ClientList(ctx Context) *redis.StringCmd func github.com/redis/go-redis/v9.StatefulCmdable.ClientPause(ctx Context, dur time.Duration) *redis.BoolCmd func github.com/redis/go-redis/v9.StatefulCmdable.ClientSetName(ctx Context, name string) *redis.BoolCmd func github.com/redis/go-redis/v9.StatefulCmdable.ClientUnblock(ctx Context, id int64) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.ClientUnblockWithError(ctx Context, id int64) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.ClientUnpause(ctx Context) *redis.BoolCmd func github.com/redis/go-redis/v9.StatefulCmdable.ClusterAddSlots(ctx Context, slots ...int) *redis.StatusCmd func github.com/redis/go-redis/v9.StatefulCmdable.ClusterAddSlotsRange(ctx Context, min, max int) *redis.StatusCmd func github.com/redis/go-redis/v9.StatefulCmdable.ClusterCountFailureReports(ctx Context, nodeID string) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.ClusterCountKeysInSlot(ctx Context, slot int) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.ClusterDelSlots(ctx Context, slots ...int) *redis.StatusCmd func github.com/redis/go-redis/v9.StatefulCmdable.ClusterDelSlotsRange(ctx Context, min, max int) *redis.StatusCmd func github.com/redis/go-redis/v9.StatefulCmdable.ClusterFailover(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.StatefulCmdable.ClusterForget(ctx Context, nodeID string) *redis.StatusCmd func github.com/redis/go-redis/v9.StatefulCmdable.ClusterGetKeysInSlot(ctx Context, slot int, count int) *redis.StringSliceCmd func github.com/redis/go-redis/v9.StatefulCmdable.ClusterInfo(ctx Context) *redis.StringCmd func github.com/redis/go-redis/v9.StatefulCmdable.ClusterKeySlot(ctx Context, key string) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.ClusterLinks(ctx Context) *redis.ClusterLinksCmd func github.com/redis/go-redis/v9.StatefulCmdable.ClusterMeet(ctx Context, host, port string) *redis.StatusCmd func github.com/redis/go-redis/v9.StatefulCmdable.ClusterNodes(ctx Context) *redis.StringCmd func github.com/redis/go-redis/v9.StatefulCmdable.ClusterReplicate(ctx Context, nodeID string) *redis.StatusCmd func github.com/redis/go-redis/v9.StatefulCmdable.ClusterResetHard(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.StatefulCmdable.ClusterResetSoft(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.StatefulCmdable.ClusterSaveConfig(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.StatefulCmdable.ClusterShards(ctx Context) *redis.ClusterShardsCmd func github.com/redis/go-redis/v9.StatefulCmdable.ClusterSlaves(ctx Context, nodeID string) *redis.StringSliceCmd func github.com/redis/go-redis/v9.StatefulCmdable.ClusterSlots(ctx Context) *redis.ClusterSlotsCmd func github.com/redis/go-redis/v9.StatefulCmdable.Command(ctx Context) *redis.CommandsInfoCmd func github.com/redis/go-redis/v9.StatefulCmdable.CommandGetKeys(ctx Context, commands ...interface{}) *redis.StringSliceCmd func github.com/redis/go-redis/v9.StatefulCmdable.CommandGetKeysAndFlags(ctx Context, commands ...interface{}) *redis.KeyFlagsCmd func github.com/redis/go-redis/v9.StatefulCmdable.CommandList(ctx Context, filter *redis.FilterBy) *redis.StringSliceCmd func github.com/redis/go-redis/v9.StatefulCmdable.ConfigGet(ctx Context, parameter string) *redis.MapStringStringCmd func github.com/redis/go-redis/v9.StatefulCmdable.ConfigResetStat(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.StatefulCmdable.ConfigRewrite(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.StatefulCmdable.ConfigSet(ctx Context, parameter, value string) *redis.StatusCmd func github.com/redis/go-redis/v9.StatefulCmdable.Copy(ctx Context, sourceKey string, destKey string, db int, replace bool) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.DBSize(ctx Context) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.DebugObject(ctx Context, key string) *redis.StringCmd func github.com/redis/go-redis/v9.StatefulCmdable.Decr(ctx Context, key string) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.DecrBy(ctx Context, key string, decrement int64) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.Del(ctx Context, keys ...string) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.Dump(ctx Context, key string) *redis.StringCmd func github.com/redis/go-redis/v9.StatefulCmdable.Echo(ctx Context, message interface{}) *redis.StringCmd func github.com/redis/go-redis/v9.StatefulCmdable.Eval(ctx Context, script string, keys []string, args ...interface{}) *redis.Cmd func github.com/redis/go-redis/v9.StatefulCmdable.EvalRO(ctx Context, script string, keys []string, args ...interface{}) *redis.Cmd func github.com/redis/go-redis/v9.StatefulCmdable.EvalSha(ctx Context, sha1 string, keys []string, args ...interface{}) *redis.Cmd func github.com/redis/go-redis/v9.StatefulCmdable.EvalShaRO(ctx Context, sha1 string, keys []string, args ...interface{}) *redis.Cmd func github.com/redis/go-redis/v9.StatefulCmdable.Exists(ctx Context, keys ...string) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.Expire(ctx Context, key string, expiration time.Duration) *redis.BoolCmd func github.com/redis/go-redis/v9.StatefulCmdable.ExpireAt(ctx Context, key string, tm time.Time) *redis.BoolCmd func github.com/redis/go-redis/v9.StatefulCmdable.ExpireGT(ctx Context, key string, expiration time.Duration) *redis.BoolCmd func github.com/redis/go-redis/v9.StatefulCmdable.ExpireLT(ctx Context, key string, expiration time.Duration) *redis.BoolCmd func github.com/redis/go-redis/v9.StatefulCmdable.ExpireNX(ctx Context, key string, expiration time.Duration) *redis.BoolCmd func github.com/redis/go-redis/v9.StatefulCmdable.ExpireTime(ctx Context, key string) *redis.DurationCmd func github.com/redis/go-redis/v9.StatefulCmdable.ExpireXX(ctx Context, key string, expiration time.Duration) *redis.BoolCmd func github.com/redis/go-redis/v9.StatefulCmdable.FCall(ctx Context, function string, keys []string, args ...interface{}) *redis.Cmd func github.com/redis/go-redis/v9.StatefulCmdable.FCallRo(ctx Context, function string, keys []string, args ...interface{}) *redis.Cmd func github.com/redis/go-redis/v9.StatefulCmdable.FlushAll(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.StatefulCmdable.FlushAllAsync(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.StatefulCmdable.FlushDB(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.StatefulCmdable.FlushDBAsync(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.StatefulCmdable.FunctionDelete(ctx Context, libName string) *redis.StringCmd func github.com/redis/go-redis/v9.StatefulCmdable.FunctionDump(ctx Context) *redis.StringCmd func github.com/redis/go-redis/v9.StatefulCmdable.FunctionFlush(ctx Context) *redis.StringCmd func github.com/redis/go-redis/v9.StatefulCmdable.FunctionFlushAsync(ctx Context) *redis.StringCmd func github.com/redis/go-redis/v9.StatefulCmdable.FunctionKill(ctx Context) *redis.StringCmd func github.com/redis/go-redis/v9.StatefulCmdable.FunctionList(ctx Context, q redis.FunctionListQuery) *redis.FunctionListCmd func github.com/redis/go-redis/v9.StatefulCmdable.FunctionLoad(ctx Context, code string) *redis.StringCmd func github.com/redis/go-redis/v9.StatefulCmdable.FunctionLoadReplace(ctx Context, code string) *redis.StringCmd func github.com/redis/go-redis/v9.StatefulCmdable.FunctionRestore(ctx Context, libDump string) *redis.StringCmd func github.com/redis/go-redis/v9.StatefulCmdable.FunctionStats(ctx Context) *redis.FunctionStatsCmd func github.com/redis/go-redis/v9.StatefulCmdable.GeoAdd(ctx Context, key string, geoLocation ...*redis.GeoLocation) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.GeoDist(ctx Context, key string, member1, member2, unit string) *redis.FloatCmd func github.com/redis/go-redis/v9.StatefulCmdable.GeoHash(ctx Context, key string, members ...string) *redis.StringSliceCmd func github.com/redis/go-redis/v9.StatefulCmdable.GeoPos(ctx Context, key string, members ...string) *redis.GeoPosCmd func github.com/redis/go-redis/v9.StatefulCmdable.GeoRadius(ctx Context, key string, longitude, latitude float64, query *redis.GeoRadiusQuery) *redis.GeoLocationCmd func github.com/redis/go-redis/v9.StatefulCmdable.GeoRadiusByMember(ctx Context, key, member string, query *redis.GeoRadiusQuery) *redis.GeoLocationCmd func github.com/redis/go-redis/v9.StatefulCmdable.GeoRadiusByMemberStore(ctx Context, key, member string, query *redis.GeoRadiusQuery) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.GeoRadiusStore(ctx Context, key string, longitude, latitude float64, query *redis.GeoRadiusQuery) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.GeoSearch(ctx Context, key string, q *redis.GeoSearchQuery) *redis.StringSliceCmd func github.com/redis/go-redis/v9.StatefulCmdable.GeoSearchLocation(ctx Context, key string, q *redis.GeoSearchLocationQuery) *redis.GeoSearchLocationCmd func github.com/redis/go-redis/v9.StatefulCmdable.GeoSearchStore(ctx Context, key, store string, q *redis.GeoSearchStoreQuery) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.Get(ctx Context, key string) *redis.StringCmd func github.com/redis/go-redis/v9.StatefulCmdable.GetBit(ctx Context, key string, offset int64) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.GetDel(ctx Context, key string) *redis.StringCmd func github.com/redis/go-redis/v9.StatefulCmdable.GetEx(ctx Context, key string, expiration time.Duration) *redis.StringCmd func github.com/redis/go-redis/v9.StatefulCmdable.GetRange(ctx Context, key string, start, end int64) *redis.StringCmd func github.com/redis/go-redis/v9.StatefulCmdable.GetSet(ctx Context, key string, value interface{}) *redis.StringCmd func github.com/redis/go-redis/v9.StatefulCmdable.HDel(ctx Context, key string, fields ...string) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.Hello(ctx Context, ver int, username, password, clientName string) *redis.MapStringInterfaceCmd func github.com/redis/go-redis/v9.StatefulCmdable.HExists(ctx Context, key, field string) *redis.BoolCmd func github.com/redis/go-redis/v9.StatefulCmdable.HGet(ctx Context, key, field string) *redis.StringCmd func github.com/redis/go-redis/v9.StatefulCmdable.HGetAll(ctx Context, key string) *redis.MapStringStringCmd func github.com/redis/go-redis/v9.StatefulCmdable.HIncrBy(ctx Context, key, field string, incr int64) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.HIncrByFloat(ctx Context, key, field string, incr float64) *redis.FloatCmd func github.com/redis/go-redis/v9.StatefulCmdable.HKeys(ctx Context, key string) *redis.StringSliceCmd func github.com/redis/go-redis/v9.StatefulCmdable.HLen(ctx Context, key string) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.HMGet(ctx Context, key string, fields ...string) *redis.SliceCmd func github.com/redis/go-redis/v9.StatefulCmdable.HMSet(ctx Context, key string, values ...interface{}) *redis.BoolCmd func github.com/redis/go-redis/v9.StatefulCmdable.HRandField(ctx Context, key string, count int) *redis.StringSliceCmd func github.com/redis/go-redis/v9.StatefulCmdable.HRandFieldWithValues(ctx Context, key string, count int) *redis.KeyValueSliceCmd func github.com/redis/go-redis/v9.StatefulCmdable.HScan(ctx Context, key string, cursor uint64, match string, count int64) *redis.ScanCmd func github.com/redis/go-redis/v9.StatefulCmdable.HSet(ctx Context, key string, values ...interface{}) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.HSetNX(ctx Context, key, field string, value interface{}) *redis.BoolCmd func github.com/redis/go-redis/v9.StatefulCmdable.HVals(ctx Context, key string) *redis.StringSliceCmd func github.com/redis/go-redis/v9.StatefulCmdable.Incr(ctx Context, key string) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.IncrBy(ctx Context, key string, value int64) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.IncrByFloat(ctx Context, key string, value float64) *redis.FloatCmd func github.com/redis/go-redis/v9.StatefulCmdable.Info(ctx Context, section ...string) *redis.StringCmd func github.com/redis/go-redis/v9.StatefulCmdable.Keys(ctx Context, pattern string) *redis.StringSliceCmd func github.com/redis/go-redis/v9.StatefulCmdable.LastSave(ctx Context) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.LCS(ctx Context, q *redis.LCSQuery) *redis.LCSCmd func github.com/redis/go-redis/v9.StatefulCmdable.LIndex(ctx Context, key string, index int64) *redis.StringCmd func github.com/redis/go-redis/v9.StatefulCmdable.LInsert(ctx Context, key, op string, pivot, value interface{}) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.LInsertAfter(ctx Context, key string, pivot, value interface{}) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.LInsertBefore(ctx Context, key string, pivot, value interface{}) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.LLen(ctx Context, key string) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.LMove(ctx Context, source, destination, srcpos, destpos string) *redis.StringCmd func github.com/redis/go-redis/v9.StatefulCmdable.LMPop(ctx Context, direction string, count int64, keys ...string) *redis.KeyValuesCmd func github.com/redis/go-redis/v9.StatefulCmdable.LPop(ctx Context, key string) *redis.StringCmd func github.com/redis/go-redis/v9.StatefulCmdable.LPopCount(ctx Context, key string, count int) *redis.StringSliceCmd func github.com/redis/go-redis/v9.StatefulCmdable.LPos(ctx Context, key string, value string, args redis.LPosArgs) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.LPosCount(ctx Context, key string, value string, count int64, args redis.LPosArgs) *redis.IntSliceCmd func github.com/redis/go-redis/v9.StatefulCmdable.LPush(ctx Context, key string, values ...interface{}) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.LPushX(ctx Context, key string, values ...interface{}) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.LRange(ctx Context, key string, start, stop int64) *redis.StringSliceCmd func github.com/redis/go-redis/v9.StatefulCmdable.LRem(ctx Context, key string, count int64, value interface{}) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.LSet(ctx Context, key string, index int64, value interface{}) *redis.StatusCmd func github.com/redis/go-redis/v9.StatefulCmdable.LTrim(ctx Context, key string, start, stop int64) *redis.StatusCmd func github.com/redis/go-redis/v9.StatefulCmdable.MemoryUsage(ctx Context, key string, samples ...int) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.MGet(ctx Context, keys ...string) *redis.SliceCmd func github.com/redis/go-redis/v9.StatefulCmdable.Migrate(ctx Context, host, port, key string, db int, timeout time.Duration) *redis.StatusCmd func github.com/redis/go-redis/v9.StatefulCmdable.Move(ctx Context, key string, db int) *redis.BoolCmd func github.com/redis/go-redis/v9.StatefulCmdable.MSet(ctx Context, values ...interface{}) *redis.StatusCmd func github.com/redis/go-redis/v9.StatefulCmdable.MSetNX(ctx Context, values ...interface{}) *redis.BoolCmd func github.com/redis/go-redis/v9.StatefulCmdable.ObjectEncoding(ctx Context, key string) *redis.StringCmd func github.com/redis/go-redis/v9.StatefulCmdable.ObjectIdleTime(ctx Context, key string) *redis.DurationCmd func github.com/redis/go-redis/v9.StatefulCmdable.ObjectRefCount(ctx Context, key string) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.Persist(ctx Context, key string) *redis.BoolCmd func github.com/redis/go-redis/v9.StatefulCmdable.PExpire(ctx Context, key string, expiration time.Duration) *redis.BoolCmd func github.com/redis/go-redis/v9.StatefulCmdable.PExpireAt(ctx Context, key string, tm time.Time) *redis.BoolCmd func github.com/redis/go-redis/v9.StatefulCmdable.PExpireTime(ctx Context, key string) *redis.DurationCmd func github.com/redis/go-redis/v9.StatefulCmdable.PFAdd(ctx Context, key string, els ...interface{}) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.PFCount(ctx Context, keys ...string) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.PFMerge(ctx Context, dest string, keys ...string) *redis.StatusCmd func github.com/redis/go-redis/v9.StatefulCmdable.Ping(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.StatefulCmdable.Pipelined(ctx Context, fn func(redis.Pipeliner) error) ([]redis.Cmder, error) func github.com/redis/go-redis/v9.StatefulCmdable.PTTL(ctx Context, key string) *redis.DurationCmd func github.com/redis/go-redis/v9.StatefulCmdable.Publish(ctx Context, channel string, message interface{}) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.PubSubChannels(ctx Context, pattern string) *redis.StringSliceCmd func github.com/redis/go-redis/v9.StatefulCmdable.PubSubNumPat(ctx Context) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.PubSubNumSub(ctx Context, channels ...string) *redis.MapStringIntCmd func github.com/redis/go-redis/v9.StatefulCmdable.PubSubShardChannels(ctx Context, pattern string) *redis.StringSliceCmd func github.com/redis/go-redis/v9.StatefulCmdable.PubSubShardNumSub(ctx Context, channels ...string) *redis.MapStringIntCmd func github.com/redis/go-redis/v9.StatefulCmdable.Quit(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.StatefulCmdable.RandomKey(ctx Context) *redis.StringCmd func github.com/redis/go-redis/v9.StatefulCmdable.ReadOnly(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.StatefulCmdable.ReadWrite(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.StatefulCmdable.Rename(ctx Context, key, newkey string) *redis.StatusCmd func github.com/redis/go-redis/v9.StatefulCmdable.RenameNX(ctx Context, key, newkey string) *redis.BoolCmd func github.com/redis/go-redis/v9.StatefulCmdable.Restore(ctx Context, key string, ttl time.Duration, value string) *redis.StatusCmd func github.com/redis/go-redis/v9.StatefulCmdable.RestoreReplace(ctx Context, key string, ttl time.Duration, value string) *redis.StatusCmd func github.com/redis/go-redis/v9.StatefulCmdable.RPop(ctx Context, key string) *redis.StringCmd func github.com/redis/go-redis/v9.StatefulCmdable.RPopCount(ctx Context, key string, count int) *redis.StringSliceCmd func github.com/redis/go-redis/v9.StatefulCmdable.RPopLPush(ctx Context, source, destination string) *redis.StringCmd func github.com/redis/go-redis/v9.StatefulCmdable.RPush(ctx Context, key string, values ...interface{}) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.RPushX(ctx Context, key string, values ...interface{}) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.SAdd(ctx Context, key string, members ...interface{}) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.Save(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.StatefulCmdable.Scan(ctx Context, cursor uint64, match string, count int64) *redis.ScanCmd func github.com/redis/go-redis/v9.StatefulCmdable.ScanType(ctx Context, cursor uint64, match string, count int64, keyType string) *redis.ScanCmd func github.com/redis/go-redis/v9.StatefulCmdable.SCard(ctx Context, key string) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.ScriptExists(ctx Context, hashes ...string) *redis.BoolSliceCmd func github.com/redis/go-redis/v9.StatefulCmdable.ScriptFlush(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.StatefulCmdable.ScriptKill(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.StatefulCmdable.ScriptLoad(ctx Context, script string) *redis.StringCmd func github.com/redis/go-redis/v9.StatefulCmdable.SDiff(ctx Context, keys ...string) *redis.StringSliceCmd func github.com/redis/go-redis/v9.StatefulCmdable.SDiffStore(ctx Context, destination string, keys ...string) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.Select(ctx Context, index int) *redis.StatusCmd func github.com/redis/go-redis/v9.StatefulCmdable.Set(ctx Context, key string, value interface{}, expiration time.Duration) *redis.StatusCmd func github.com/redis/go-redis/v9.StatefulCmdable.SetArgs(ctx Context, key string, value interface{}, a redis.SetArgs) *redis.StatusCmd func github.com/redis/go-redis/v9.StatefulCmdable.SetBit(ctx Context, key string, offset int64, value int) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.SetEx(ctx Context, key string, value interface{}, expiration time.Duration) *redis.StatusCmd func github.com/redis/go-redis/v9.StatefulCmdable.SetNX(ctx Context, key string, value interface{}, expiration time.Duration) *redis.BoolCmd func github.com/redis/go-redis/v9.StatefulCmdable.SetRange(ctx Context, key string, offset int64, value string) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.SetXX(ctx Context, key string, value interface{}, expiration time.Duration) *redis.BoolCmd func github.com/redis/go-redis/v9.StatefulCmdable.Shutdown(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.StatefulCmdable.ShutdownNoSave(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.StatefulCmdable.ShutdownSave(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.StatefulCmdable.SInter(ctx Context, keys ...string) *redis.StringSliceCmd func github.com/redis/go-redis/v9.StatefulCmdable.SInterCard(ctx Context, limit int64, keys ...string) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.SInterStore(ctx Context, destination string, keys ...string) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.SIsMember(ctx Context, key string, member interface{}) *redis.BoolCmd func github.com/redis/go-redis/v9.StatefulCmdable.SlaveOf(ctx Context, host, port string) *redis.StatusCmd func github.com/redis/go-redis/v9.StatefulCmdable.SlowLogGet(ctx Context, num int64) *redis.SlowLogCmd func github.com/redis/go-redis/v9.StatefulCmdable.SMembers(ctx Context, key string) *redis.StringSliceCmd func github.com/redis/go-redis/v9.StatefulCmdable.SMembersMap(ctx Context, key string) *redis.StringStructMapCmd func github.com/redis/go-redis/v9.StatefulCmdable.SMIsMember(ctx Context, key string, members ...interface{}) *redis.BoolSliceCmd func github.com/redis/go-redis/v9.StatefulCmdable.SMove(ctx Context, source, destination string, member interface{}) *redis.BoolCmd func github.com/redis/go-redis/v9.StatefulCmdable.Sort(ctx Context, key string, sort *redis.Sort) *redis.StringSliceCmd func github.com/redis/go-redis/v9.StatefulCmdable.SortInterfaces(ctx Context, key string, sort *redis.Sort) *redis.SliceCmd func github.com/redis/go-redis/v9.StatefulCmdable.SortRO(ctx Context, key string, sort *redis.Sort) *redis.StringSliceCmd func github.com/redis/go-redis/v9.StatefulCmdable.SortStore(ctx Context, key, store string, sort *redis.Sort) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.SPop(ctx Context, key string) *redis.StringCmd func github.com/redis/go-redis/v9.StatefulCmdable.SPopN(ctx Context, key string, count int64) *redis.StringSliceCmd func github.com/redis/go-redis/v9.StatefulCmdable.SPublish(ctx Context, channel string, message interface{}) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.SRandMember(ctx Context, key string) *redis.StringCmd func github.com/redis/go-redis/v9.StatefulCmdable.SRandMemberN(ctx Context, key string, count int64) *redis.StringSliceCmd func github.com/redis/go-redis/v9.StatefulCmdable.SRem(ctx Context, key string, members ...interface{}) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.SScan(ctx Context, key string, cursor uint64, match string, count int64) *redis.ScanCmd func github.com/redis/go-redis/v9.StatefulCmdable.StrLen(ctx Context, key string) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.SUnion(ctx Context, keys ...string) *redis.StringSliceCmd func github.com/redis/go-redis/v9.StatefulCmdable.SUnionStore(ctx Context, destination string, keys ...string) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.SwapDB(ctx Context, index1, index2 int) *redis.StatusCmd func github.com/redis/go-redis/v9.StatefulCmdable.Time(ctx Context) *redis.TimeCmd func github.com/redis/go-redis/v9.StatefulCmdable.Touch(ctx Context, keys ...string) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.TTL(ctx Context, key string) *redis.DurationCmd func github.com/redis/go-redis/v9.StatefulCmdable.TxPipelined(ctx Context, fn func(redis.Pipeliner) error) ([]redis.Cmder, error) func github.com/redis/go-redis/v9.StatefulCmdable.Type(ctx Context, key string) *redis.StatusCmd func github.com/redis/go-redis/v9.StatefulCmdable.Unlink(ctx Context, keys ...string) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.XAck(ctx Context, stream, group string, ids ...string) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.XAdd(ctx Context, a *redis.XAddArgs) *redis.StringCmd func github.com/redis/go-redis/v9.StatefulCmdable.XAutoClaim(ctx Context, a *redis.XAutoClaimArgs) *redis.XAutoClaimCmd func github.com/redis/go-redis/v9.StatefulCmdable.XAutoClaimJustID(ctx Context, a *redis.XAutoClaimArgs) *redis.XAutoClaimJustIDCmd func github.com/redis/go-redis/v9.StatefulCmdable.XClaim(ctx Context, a *redis.XClaimArgs) *redis.XMessageSliceCmd func github.com/redis/go-redis/v9.StatefulCmdable.XClaimJustID(ctx Context, a *redis.XClaimArgs) *redis.StringSliceCmd func github.com/redis/go-redis/v9.StatefulCmdable.XDel(ctx Context, stream string, ids ...string) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.XGroupCreate(ctx Context, stream, group, start string) *redis.StatusCmd func github.com/redis/go-redis/v9.StatefulCmdable.XGroupCreateConsumer(ctx Context, stream, group, consumer string) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.XGroupCreateMkStream(ctx Context, stream, group, start string) *redis.StatusCmd func github.com/redis/go-redis/v9.StatefulCmdable.XGroupDelConsumer(ctx Context, stream, group, consumer string) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.XGroupDestroy(ctx Context, stream, group string) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.XGroupSetID(ctx Context, stream, group, start string) *redis.StatusCmd func github.com/redis/go-redis/v9.StatefulCmdable.XInfoConsumers(ctx Context, key string, group string) *redis.XInfoConsumersCmd func github.com/redis/go-redis/v9.StatefulCmdable.XInfoGroups(ctx Context, key string) *redis.XInfoGroupsCmd func github.com/redis/go-redis/v9.StatefulCmdable.XInfoStream(ctx Context, key string) *redis.XInfoStreamCmd func github.com/redis/go-redis/v9.StatefulCmdable.XInfoStreamFull(ctx Context, key string, count int) *redis.XInfoStreamFullCmd func github.com/redis/go-redis/v9.StatefulCmdable.XLen(ctx Context, stream string) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.XPending(ctx Context, stream, group string) *redis.XPendingCmd func github.com/redis/go-redis/v9.StatefulCmdable.XPendingExt(ctx Context, a *redis.XPendingExtArgs) *redis.XPendingExtCmd func github.com/redis/go-redis/v9.StatefulCmdable.XRange(ctx Context, stream, start, stop string) *redis.XMessageSliceCmd func github.com/redis/go-redis/v9.StatefulCmdable.XRangeN(ctx Context, stream, start, stop string, count int64) *redis.XMessageSliceCmd func github.com/redis/go-redis/v9.StatefulCmdable.XRead(ctx Context, a *redis.XReadArgs) *redis.XStreamSliceCmd func github.com/redis/go-redis/v9.StatefulCmdable.XReadGroup(ctx Context, a *redis.XReadGroupArgs) *redis.XStreamSliceCmd func github.com/redis/go-redis/v9.StatefulCmdable.XReadStreams(ctx Context, streams ...string) *redis.XStreamSliceCmd func github.com/redis/go-redis/v9.StatefulCmdable.XRevRange(ctx Context, stream string, start, stop string) *redis.XMessageSliceCmd func github.com/redis/go-redis/v9.StatefulCmdable.XRevRangeN(ctx Context, stream string, start, stop string, count int64) *redis.XMessageSliceCmd func github.com/redis/go-redis/v9.StatefulCmdable.XTrimMaxLen(ctx Context, key string, maxLen int64) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.XTrimMaxLenApprox(ctx Context, key string, maxLen, limit int64) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.XTrimMinID(ctx Context, key string, minID string) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.XTrimMinIDApprox(ctx Context, key string, minID string, limit int64) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.ZAdd(ctx Context, key string, members ...redis.Z) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.ZAddArgs(ctx Context, key string, args redis.ZAddArgs) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.ZAddArgsIncr(ctx Context, key string, args redis.ZAddArgs) *redis.FloatCmd func github.com/redis/go-redis/v9.StatefulCmdable.ZAddGT(ctx Context, key string, members ...redis.Z) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.ZAddLT(ctx Context, key string, members ...redis.Z) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.ZAddNX(ctx Context, key string, members ...redis.Z) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.ZAddXX(ctx Context, key string, members ...redis.Z) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.ZCard(ctx Context, key string) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.ZCount(ctx Context, key, min, max string) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.ZDiff(ctx Context, keys ...string) *redis.StringSliceCmd func github.com/redis/go-redis/v9.StatefulCmdable.ZDiffStore(ctx Context, destination string, keys ...string) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.ZDiffWithScores(ctx Context, keys ...string) *redis.ZSliceCmd func github.com/redis/go-redis/v9.StatefulCmdable.ZIncrBy(ctx Context, key string, increment float64, member string) *redis.FloatCmd func github.com/redis/go-redis/v9.StatefulCmdable.ZInter(ctx Context, store *redis.ZStore) *redis.StringSliceCmd func github.com/redis/go-redis/v9.StatefulCmdable.ZInterCard(ctx Context, limit int64, keys ...string) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.ZInterStore(ctx Context, destination string, store *redis.ZStore) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.ZInterWithScores(ctx Context, store *redis.ZStore) *redis.ZSliceCmd func github.com/redis/go-redis/v9.StatefulCmdable.ZLexCount(ctx Context, key, min, max string) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.ZMPop(ctx Context, order string, count int64, keys ...string) *redis.ZSliceWithKeyCmd func github.com/redis/go-redis/v9.StatefulCmdable.ZMScore(ctx Context, key string, members ...string) *redis.FloatSliceCmd func github.com/redis/go-redis/v9.StatefulCmdable.ZPopMax(ctx Context, key string, count ...int64) *redis.ZSliceCmd func github.com/redis/go-redis/v9.StatefulCmdable.ZPopMin(ctx Context, key string, count ...int64) *redis.ZSliceCmd func github.com/redis/go-redis/v9.StatefulCmdable.ZRandMember(ctx Context, key string, count int) *redis.StringSliceCmd func github.com/redis/go-redis/v9.StatefulCmdable.ZRandMemberWithScores(ctx Context, key string, count int) *redis.ZSliceCmd func github.com/redis/go-redis/v9.StatefulCmdable.ZRange(ctx Context, key string, start, stop int64) *redis.StringSliceCmd func github.com/redis/go-redis/v9.StatefulCmdable.ZRangeArgs(ctx Context, z redis.ZRangeArgs) *redis.StringSliceCmd func github.com/redis/go-redis/v9.StatefulCmdable.ZRangeArgsWithScores(ctx Context, z redis.ZRangeArgs) *redis.ZSliceCmd func github.com/redis/go-redis/v9.StatefulCmdable.ZRangeByLex(ctx Context, key string, opt *redis.ZRangeBy) *redis.StringSliceCmd func github.com/redis/go-redis/v9.StatefulCmdable.ZRangeByScore(ctx Context, key string, opt *redis.ZRangeBy) *redis.StringSliceCmd func github.com/redis/go-redis/v9.StatefulCmdable.ZRangeByScoreWithScores(ctx Context, key string, opt *redis.ZRangeBy) *redis.ZSliceCmd func github.com/redis/go-redis/v9.StatefulCmdable.ZRangeStore(ctx Context, dst string, z redis.ZRangeArgs) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.ZRangeWithScores(ctx Context, key string, start, stop int64) *redis.ZSliceCmd func github.com/redis/go-redis/v9.StatefulCmdable.ZRank(ctx Context, key, member string) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.ZRem(ctx Context, key string, members ...interface{}) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.ZRemRangeByLex(ctx Context, key, min, max string) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.ZRemRangeByRank(ctx Context, key string, start, stop int64) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.ZRemRangeByScore(ctx Context, key, min, max string) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.ZRevRange(ctx Context, key string, start, stop int64) *redis.StringSliceCmd func github.com/redis/go-redis/v9.StatefulCmdable.ZRevRangeByLex(ctx Context, key string, opt *redis.ZRangeBy) *redis.StringSliceCmd func github.com/redis/go-redis/v9.StatefulCmdable.ZRevRangeByScore(ctx Context, key string, opt *redis.ZRangeBy) *redis.StringSliceCmd func github.com/redis/go-redis/v9.StatefulCmdable.ZRevRangeByScoreWithScores(ctx Context, key string, opt *redis.ZRangeBy) *redis.ZSliceCmd func github.com/redis/go-redis/v9.StatefulCmdable.ZRevRangeWithScores(ctx Context, key string, start, stop int64) *redis.ZSliceCmd func github.com/redis/go-redis/v9.StatefulCmdable.ZRevRank(ctx Context, key, member string) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.ZScan(ctx Context, key string, cursor uint64, match string, count int64) *redis.ScanCmd func github.com/redis/go-redis/v9.StatefulCmdable.ZScore(ctx Context, key, member string) *redis.FloatCmd func github.com/redis/go-redis/v9.StatefulCmdable.ZUnion(ctx Context, store redis.ZStore) *redis.StringSliceCmd func github.com/redis/go-redis/v9.StatefulCmdable.ZUnionStore(ctx Context, dest string, store *redis.ZStore) *redis.IntCmd func github.com/redis/go-redis/v9.StatefulCmdable.ZUnionWithScores(ctx Context, store redis.ZStore) *redis.ZSliceCmd func github.com/redis/go-redis/v9.(*Tx).Close(ctx Context) error func github.com/redis/go-redis/v9.(*Tx).Pipelined(ctx Context, fn func(redis.Pipeliner) error) ([]redis.Cmder, error) func github.com/redis/go-redis/v9.(*Tx).Process(ctx Context, cmd redis.Cmder) error func github.com/redis/go-redis/v9.(*Tx).TxPipelined(ctx Context, fn func(redis.Pipeliner) error) ([]redis.Cmder, error) func github.com/redis/go-redis/v9.(*Tx).Unwatch(ctx Context, keys ...string) *redis.StatusCmd func github.com/redis/go-redis/v9.(*Tx).Watch(ctx Context, keys ...string) *redis.StatusCmd func github.com/redis/go-redis/v9.UniversalClient.ACLDryRun(ctx Context, username string, command ...interface{}) *redis.StringCmd func github.com/redis/go-redis/v9.UniversalClient.Append(ctx Context, key, value string) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.BgRewriteAOF(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.UniversalClient.BgSave(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.UniversalClient.BitCount(ctx Context, key string, bitCount *redis.BitCount) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.BitField(ctx Context, key string, args ...interface{}) *redis.IntSliceCmd func github.com/redis/go-redis/v9.UniversalClient.BitOpAnd(ctx Context, destKey string, keys ...string) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.BitOpNot(ctx Context, destKey string, key string) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.BitOpOr(ctx Context, destKey string, keys ...string) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.BitOpXor(ctx Context, destKey string, keys ...string) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.BitPos(ctx Context, key string, bit int64, pos ...int64) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.BitPosSpan(ctx Context, key string, bit int8, start, end int64, span string) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.BLMove(ctx Context, source, destination, srcpos, destpos string, timeout time.Duration) *redis.StringCmd func github.com/redis/go-redis/v9.UniversalClient.BLMPop(ctx Context, timeout time.Duration, direction string, count int64, keys ...string) *redis.KeyValuesCmd func github.com/redis/go-redis/v9.UniversalClient.BLPop(ctx Context, timeout time.Duration, keys ...string) *redis.StringSliceCmd func github.com/redis/go-redis/v9.UniversalClient.BRPop(ctx Context, timeout time.Duration, keys ...string) *redis.StringSliceCmd func github.com/redis/go-redis/v9.UniversalClient.BRPopLPush(ctx Context, source, destination string, timeout time.Duration) *redis.StringCmd func github.com/redis/go-redis/v9.UniversalClient.BZMPop(ctx Context, timeout time.Duration, order string, count int64, keys ...string) *redis.ZSliceWithKeyCmd func github.com/redis/go-redis/v9.UniversalClient.BZPopMax(ctx Context, timeout time.Duration, keys ...string) *redis.ZWithKeyCmd func github.com/redis/go-redis/v9.UniversalClient.BZPopMin(ctx Context, timeout time.Duration, keys ...string) *redis.ZWithKeyCmd func github.com/redis/go-redis/v9.UniversalClient.ClientGetName(ctx Context) *redis.StringCmd func github.com/redis/go-redis/v9.UniversalClient.ClientID(ctx Context) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.ClientKill(ctx Context, ipPort string) *redis.StatusCmd func github.com/redis/go-redis/v9.UniversalClient.ClientKillByFilter(ctx Context, keys ...string) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.ClientList(ctx Context) *redis.StringCmd func github.com/redis/go-redis/v9.UniversalClient.ClientPause(ctx Context, dur time.Duration) *redis.BoolCmd func github.com/redis/go-redis/v9.UniversalClient.ClientUnblock(ctx Context, id int64) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.ClientUnblockWithError(ctx Context, id int64) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.ClientUnpause(ctx Context) *redis.BoolCmd func github.com/redis/go-redis/v9.UniversalClient.ClusterAddSlots(ctx Context, slots ...int) *redis.StatusCmd func github.com/redis/go-redis/v9.UniversalClient.ClusterAddSlotsRange(ctx Context, min, max int) *redis.StatusCmd func github.com/redis/go-redis/v9.UniversalClient.ClusterCountFailureReports(ctx Context, nodeID string) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.ClusterCountKeysInSlot(ctx Context, slot int) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.ClusterDelSlots(ctx Context, slots ...int) *redis.StatusCmd func github.com/redis/go-redis/v9.UniversalClient.ClusterDelSlotsRange(ctx Context, min, max int) *redis.StatusCmd func github.com/redis/go-redis/v9.UniversalClient.ClusterFailover(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.UniversalClient.ClusterForget(ctx Context, nodeID string) *redis.StatusCmd func github.com/redis/go-redis/v9.UniversalClient.ClusterGetKeysInSlot(ctx Context, slot int, count int) *redis.StringSliceCmd func github.com/redis/go-redis/v9.UniversalClient.ClusterInfo(ctx Context) *redis.StringCmd func github.com/redis/go-redis/v9.UniversalClient.ClusterKeySlot(ctx Context, key string) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.ClusterLinks(ctx Context) *redis.ClusterLinksCmd func github.com/redis/go-redis/v9.UniversalClient.ClusterMeet(ctx Context, host, port string) *redis.StatusCmd func github.com/redis/go-redis/v9.UniversalClient.ClusterNodes(ctx Context) *redis.StringCmd func github.com/redis/go-redis/v9.UniversalClient.ClusterReplicate(ctx Context, nodeID string) *redis.StatusCmd func github.com/redis/go-redis/v9.UniversalClient.ClusterResetHard(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.UniversalClient.ClusterResetSoft(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.UniversalClient.ClusterSaveConfig(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.UniversalClient.ClusterShards(ctx Context) *redis.ClusterShardsCmd func github.com/redis/go-redis/v9.UniversalClient.ClusterSlaves(ctx Context, nodeID string) *redis.StringSliceCmd func github.com/redis/go-redis/v9.UniversalClient.ClusterSlots(ctx Context) *redis.ClusterSlotsCmd func github.com/redis/go-redis/v9.UniversalClient.Command(ctx Context) *redis.CommandsInfoCmd func github.com/redis/go-redis/v9.UniversalClient.CommandGetKeys(ctx Context, commands ...interface{}) *redis.StringSliceCmd func github.com/redis/go-redis/v9.UniversalClient.CommandGetKeysAndFlags(ctx Context, commands ...interface{}) *redis.KeyFlagsCmd func github.com/redis/go-redis/v9.UniversalClient.CommandList(ctx Context, filter *redis.FilterBy) *redis.StringSliceCmd func github.com/redis/go-redis/v9.UniversalClient.ConfigGet(ctx Context, parameter string) *redis.MapStringStringCmd func github.com/redis/go-redis/v9.UniversalClient.ConfigResetStat(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.UniversalClient.ConfigRewrite(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.UniversalClient.ConfigSet(ctx Context, parameter, value string) *redis.StatusCmd func github.com/redis/go-redis/v9.UniversalClient.Copy(ctx Context, sourceKey string, destKey string, db int, replace bool) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.DBSize(ctx Context) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.DebugObject(ctx Context, key string) *redis.StringCmd func github.com/redis/go-redis/v9.UniversalClient.Decr(ctx Context, key string) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.DecrBy(ctx Context, key string, decrement int64) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.Del(ctx Context, keys ...string) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.Do(ctx Context, args ...interface{}) *redis.Cmd func github.com/redis/go-redis/v9.UniversalClient.Dump(ctx Context, key string) *redis.StringCmd func github.com/redis/go-redis/v9.UniversalClient.Echo(ctx Context, message interface{}) *redis.StringCmd func github.com/redis/go-redis/v9.UniversalClient.Eval(ctx Context, script string, keys []string, args ...interface{}) *redis.Cmd func github.com/redis/go-redis/v9.UniversalClient.EvalRO(ctx Context, script string, keys []string, args ...interface{}) *redis.Cmd func github.com/redis/go-redis/v9.UniversalClient.EvalSha(ctx Context, sha1 string, keys []string, args ...interface{}) *redis.Cmd func github.com/redis/go-redis/v9.UniversalClient.EvalShaRO(ctx Context, sha1 string, keys []string, args ...interface{}) *redis.Cmd func github.com/redis/go-redis/v9.UniversalClient.Exists(ctx Context, keys ...string) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.Expire(ctx Context, key string, expiration time.Duration) *redis.BoolCmd func github.com/redis/go-redis/v9.UniversalClient.ExpireAt(ctx Context, key string, tm time.Time) *redis.BoolCmd func github.com/redis/go-redis/v9.UniversalClient.ExpireGT(ctx Context, key string, expiration time.Duration) *redis.BoolCmd func github.com/redis/go-redis/v9.UniversalClient.ExpireLT(ctx Context, key string, expiration time.Duration) *redis.BoolCmd func github.com/redis/go-redis/v9.UniversalClient.ExpireNX(ctx Context, key string, expiration time.Duration) *redis.BoolCmd func github.com/redis/go-redis/v9.UniversalClient.ExpireTime(ctx Context, key string) *redis.DurationCmd func github.com/redis/go-redis/v9.UniversalClient.ExpireXX(ctx Context, key string, expiration time.Duration) *redis.BoolCmd func github.com/redis/go-redis/v9.UniversalClient.FCall(ctx Context, function string, keys []string, args ...interface{}) *redis.Cmd func github.com/redis/go-redis/v9.UniversalClient.FCallRo(ctx Context, function string, keys []string, args ...interface{}) *redis.Cmd func github.com/redis/go-redis/v9.UniversalClient.FlushAll(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.UniversalClient.FlushAllAsync(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.UniversalClient.FlushDB(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.UniversalClient.FlushDBAsync(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.UniversalClient.FunctionDelete(ctx Context, libName string) *redis.StringCmd func github.com/redis/go-redis/v9.UniversalClient.FunctionDump(ctx Context) *redis.StringCmd func github.com/redis/go-redis/v9.UniversalClient.FunctionFlush(ctx Context) *redis.StringCmd func github.com/redis/go-redis/v9.UniversalClient.FunctionFlushAsync(ctx Context) *redis.StringCmd func github.com/redis/go-redis/v9.UniversalClient.FunctionKill(ctx Context) *redis.StringCmd func github.com/redis/go-redis/v9.UniversalClient.FunctionList(ctx Context, q redis.FunctionListQuery) *redis.FunctionListCmd func github.com/redis/go-redis/v9.UniversalClient.FunctionLoad(ctx Context, code string) *redis.StringCmd func github.com/redis/go-redis/v9.UniversalClient.FunctionLoadReplace(ctx Context, code string) *redis.StringCmd func github.com/redis/go-redis/v9.UniversalClient.FunctionRestore(ctx Context, libDump string) *redis.StringCmd func github.com/redis/go-redis/v9.UniversalClient.FunctionStats(ctx Context) *redis.FunctionStatsCmd func github.com/redis/go-redis/v9.UniversalClient.GeoAdd(ctx Context, key string, geoLocation ...*redis.GeoLocation) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.GeoDist(ctx Context, key string, member1, member2, unit string) *redis.FloatCmd func github.com/redis/go-redis/v9.UniversalClient.GeoHash(ctx Context, key string, members ...string) *redis.StringSliceCmd func github.com/redis/go-redis/v9.UniversalClient.GeoPos(ctx Context, key string, members ...string) *redis.GeoPosCmd func github.com/redis/go-redis/v9.UniversalClient.GeoRadius(ctx Context, key string, longitude, latitude float64, query *redis.GeoRadiusQuery) *redis.GeoLocationCmd func github.com/redis/go-redis/v9.UniversalClient.GeoRadiusByMember(ctx Context, key, member string, query *redis.GeoRadiusQuery) *redis.GeoLocationCmd func github.com/redis/go-redis/v9.UniversalClient.GeoRadiusByMemberStore(ctx Context, key, member string, query *redis.GeoRadiusQuery) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.GeoRadiusStore(ctx Context, key string, longitude, latitude float64, query *redis.GeoRadiusQuery) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.GeoSearch(ctx Context, key string, q *redis.GeoSearchQuery) *redis.StringSliceCmd func github.com/redis/go-redis/v9.UniversalClient.GeoSearchLocation(ctx Context, key string, q *redis.GeoSearchLocationQuery) *redis.GeoSearchLocationCmd func github.com/redis/go-redis/v9.UniversalClient.GeoSearchStore(ctx Context, key, store string, q *redis.GeoSearchStoreQuery) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.Get(ctx Context, key string) *redis.StringCmd func github.com/redis/go-redis/v9.UniversalClient.GetBit(ctx Context, key string, offset int64) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.GetDel(ctx Context, key string) *redis.StringCmd func github.com/redis/go-redis/v9.UniversalClient.GetEx(ctx Context, key string, expiration time.Duration) *redis.StringCmd func github.com/redis/go-redis/v9.UniversalClient.GetRange(ctx Context, key string, start, end int64) *redis.StringCmd func github.com/redis/go-redis/v9.UniversalClient.GetSet(ctx Context, key string, value interface{}) *redis.StringCmd func github.com/redis/go-redis/v9.UniversalClient.HDel(ctx Context, key string, fields ...string) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.HExists(ctx Context, key, field string) *redis.BoolCmd func github.com/redis/go-redis/v9.UniversalClient.HGet(ctx Context, key, field string) *redis.StringCmd func github.com/redis/go-redis/v9.UniversalClient.HGetAll(ctx Context, key string) *redis.MapStringStringCmd func github.com/redis/go-redis/v9.UniversalClient.HIncrBy(ctx Context, key, field string, incr int64) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.HIncrByFloat(ctx Context, key, field string, incr float64) *redis.FloatCmd func github.com/redis/go-redis/v9.UniversalClient.HKeys(ctx Context, key string) *redis.StringSliceCmd func github.com/redis/go-redis/v9.UniversalClient.HLen(ctx Context, key string) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.HMGet(ctx Context, key string, fields ...string) *redis.SliceCmd func github.com/redis/go-redis/v9.UniversalClient.HMSet(ctx Context, key string, values ...interface{}) *redis.BoolCmd func github.com/redis/go-redis/v9.UniversalClient.HRandField(ctx Context, key string, count int) *redis.StringSliceCmd func github.com/redis/go-redis/v9.UniversalClient.HRandFieldWithValues(ctx Context, key string, count int) *redis.KeyValueSliceCmd func github.com/redis/go-redis/v9.UniversalClient.HScan(ctx Context, key string, cursor uint64, match string, count int64) *redis.ScanCmd func github.com/redis/go-redis/v9.UniversalClient.HSet(ctx Context, key string, values ...interface{}) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.HSetNX(ctx Context, key, field string, value interface{}) *redis.BoolCmd func github.com/redis/go-redis/v9.UniversalClient.HVals(ctx Context, key string) *redis.StringSliceCmd func github.com/redis/go-redis/v9.UniversalClient.Incr(ctx Context, key string) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.IncrBy(ctx Context, key string, value int64) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.IncrByFloat(ctx Context, key string, value float64) *redis.FloatCmd func github.com/redis/go-redis/v9.UniversalClient.Info(ctx Context, section ...string) *redis.StringCmd func github.com/redis/go-redis/v9.UniversalClient.Keys(ctx Context, pattern string) *redis.StringSliceCmd func github.com/redis/go-redis/v9.UniversalClient.LastSave(ctx Context) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.LCS(ctx Context, q *redis.LCSQuery) *redis.LCSCmd func github.com/redis/go-redis/v9.UniversalClient.LIndex(ctx Context, key string, index int64) *redis.StringCmd func github.com/redis/go-redis/v9.UniversalClient.LInsert(ctx Context, key, op string, pivot, value interface{}) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.LInsertAfter(ctx Context, key string, pivot, value interface{}) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.LInsertBefore(ctx Context, key string, pivot, value interface{}) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.LLen(ctx Context, key string) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.LMove(ctx Context, source, destination, srcpos, destpos string) *redis.StringCmd func github.com/redis/go-redis/v9.UniversalClient.LMPop(ctx Context, direction string, count int64, keys ...string) *redis.KeyValuesCmd func github.com/redis/go-redis/v9.UniversalClient.LPop(ctx Context, key string) *redis.StringCmd func github.com/redis/go-redis/v9.UniversalClient.LPopCount(ctx Context, key string, count int) *redis.StringSliceCmd func github.com/redis/go-redis/v9.UniversalClient.LPos(ctx Context, key string, value string, args redis.LPosArgs) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.LPosCount(ctx Context, key string, value string, count int64, args redis.LPosArgs) *redis.IntSliceCmd func github.com/redis/go-redis/v9.UniversalClient.LPush(ctx Context, key string, values ...interface{}) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.LPushX(ctx Context, key string, values ...interface{}) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.LRange(ctx Context, key string, start, stop int64) *redis.StringSliceCmd func github.com/redis/go-redis/v9.UniversalClient.LRem(ctx Context, key string, count int64, value interface{}) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.LSet(ctx Context, key string, index int64, value interface{}) *redis.StatusCmd func github.com/redis/go-redis/v9.UniversalClient.LTrim(ctx Context, key string, start, stop int64) *redis.StatusCmd func github.com/redis/go-redis/v9.UniversalClient.MemoryUsage(ctx Context, key string, samples ...int) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.MGet(ctx Context, keys ...string) *redis.SliceCmd func github.com/redis/go-redis/v9.UniversalClient.Migrate(ctx Context, host, port, key string, db int, timeout time.Duration) *redis.StatusCmd func github.com/redis/go-redis/v9.UniversalClient.Move(ctx Context, key string, db int) *redis.BoolCmd func github.com/redis/go-redis/v9.UniversalClient.MSet(ctx Context, values ...interface{}) *redis.StatusCmd func github.com/redis/go-redis/v9.UniversalClient.MSetNX(ctx Context, values ...interface{}) *redis.BoolCmd func github.com/redis/go-redis/v9.UniversalClient.ObjectEncoding(ctx Context, key string) *redis.StringCmd func github.com/redis/go-redis/v9.UniversalClient.ObjectIdleTime(ctx Context, key string) *redis.DurationCmd func github.com/redis/go-redis/v9.UniversalClient.ObjectRefCount(ctx Context, key string) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.Persist(ctx Context, key string) *redis.BoolCmd func github.com/redis/go-redis/v9.UniversalClient.PExpire(ctx Context, key string, expiration time.Duration) *redis.BoolCmd func github.com/redis/go-redis/v9.UniversalClient.PExpireAt(ctx Context, key string, tm time.Time) *redis.BoolCmd func github.com/redis/go-redis/v9.UniversalClient.PExpireTime(ctx Context, key string) *redis.DurationCmd func github.com/redis/go-redis/v9.UniversalClient.PFAdd(ctx Context, key string, els ...interface{}) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.PFCount(ctx Context, keys ...string) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.PFMerge(ctx Context, dest string, keys ...string) *redis.StatusCmd func github.com/redis/go-redis/v9.UniversalClient.Ping(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.UniversalClient.Pipelined(ctx Context, fn func(redis.Pipeliner) error) ([]redis.Cmder, error) func github.com/redis/go-redis/v9.UniversalClient.Process(ctx Context, cmd redis.Cmder) error func github.com/redis/go-redis/v9.UniversalClient.PSubscribe(ctx Context, channels ...string) *redis.PubSub func github.com/redis/go-redis/v9.UniversalClient.PTTL(ctx Context, key string) *redis.DurationCmd func github.com/redis/go-redis/v9.UniversalClient.Publish(ctx Context, channel string, message interface{}) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.PubSubChannels(ctx Context, pattern string) *redis.StringSliceCmd func github.com/redis/go-redis/v9.UniversalClient.PubSubNumPat(ctx Context) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.PubSubNumSub(ctx Context, channels ...string) *redis.MapStringIntCmd func github.com/redis/go-redis/v9.UniversalClient.PubSubShardChannels(ctx Context, pattern string) *redis.StringSliceCmd func github.com/redis/go-redis/v9.UniversalClient.PubSubShardNumSub(ctx Context, channels ...string) *redis.MapStringIntCmd func github.com/redis/go-redis/v9.UniversalClient.Quit(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.UniversalClient.RandomKey(ctx Context) *redis.StringCmd func github.com/redis/go-redis/v9.UniversalClient.ReadOnly(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.UniversalClient.ReadWrite(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.UniversalClient.Rename(ctx Context, key, newkey string) *redis.StatusCmd func github.com/redis/go-redis/v9.UniversalClient.RenameNX(ctx Context, key, newkey string) *redis.BoolCmd func github.com/redis/go-redis/v9.UniversalClient.Restore(ctx Context, key string, ttl time.Duration, value string) *redis.StatusCmd func github.com/redis/go-redis/v9.UniversalClient.RestoreReplace(ctx Context, key string, ttl time.Duration, value string) *redis.StatusCmd func github.com/redis/go-redis/v9.UniversalClient.RPop(ctx Context, key string) *redis.StringCmd func github.com/redis/go-redis/v9.UniversalClient.RPopCount(ctx Context, key string, count int) *redis.StringSliceCmd func github.com/redis/go-redis/v9.UniversalClient.RPopLPush(ctx Context, source, destination string) *redis.StringCmd func github.com/redis/go-redis/v9.UniversalClient.RPush(ctx Context, key string, values ...interface{}) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.RPushX(ctx Context, key string, values ...interface{}) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.SAdd(ctx Context, key string, members ...interface{}) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.Save(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.UniversalClient.Scan(ctx Context, cursor uint64, match string, count int64) *redis.ScanCmd func github.com/redis/go-redis/v9.UniversalClient.ScanType(ctx Context, cursor uint64, match string, count int64, keyType string) *redis.ScanCmd func github.com/redis/go-redis/v9.UniversalClient.SCard(ctx Context, key string) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.ScriptExists(ctx Context, hashes ...string) *redis.BoolSliceCmd func github.com/redis/go-redis/v9.UniversalClient.ScriptFlush(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.UniversalClient.ScriptKill(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.UniversalClient.ScriptLoad(ctx Context, script string) *redis.StringCmd func github.com/redis/go-redis/v9.UniversalClient.SDiff(ctx Context, keys ...string) *redis.StringSliceCmd func github.com/redis/go-redis/v9.UniversalClient.SDiffStore(ctx Context, destination string, keys ...string) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.Set(ctx Context, key string, value interface{}, expiration time.Duration) *redis.StatusCmd func github.com/redis/go-redis/v9.UniversalClient.SetArgs(ctx Context, key string, value interface{}, a redis.SetArgs) *redis.StatusCmd func github.com/redis/go-redis/v9.UniversalClient.SetBit(ctx Context, key string, offset int64, value int) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.SetEx(ctx Context, key string, value interface{}, expiration time.Duration) *redis.StatusCmd func github.com/redis/go-redis/v9.UniversalClient.SetNX(ctx Context, key string, value interface{}, expiration time.Duration) *redis.BoolCmd func github.com/redis/go-redis/v9.UniversalClient.SetRange(ctx Context, key string, offset int64, value string) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.SetXX(ctx Context, key string, value interface{}, expiration time.Duration) *redis.BoolCmd func github.com/redis/go-redis/v9.UniversalClient.Shutdown(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.UniversalClient.ShutdownNoSave(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.UniversalClient.ShutdownSave(ctx Context) *redis.StatusCmd func github.com/redis/go-redis/v9.UniversalClient.SInter(ctx Context, keys ...string) *redis.StringSliceCmd func github.com/redis/go-redis/v9.UniversalClient.SInterCard(ctx Context, limit int64, keys ...string) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.SInterStore(ctx Context, destination string, keys ...string) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.SIsMember(ctx Context, key string, member interface{}) *redis.BoolCmd func github.com/redis/go-redis/v9.UniversalClient.SlaveOf(ctx Context, host, port string) *redis.StatusCmd func github.com/redis/go-redis/v9.UniversalClient.SlowLogGet(ctx Context, num int64) *redis.SlowLogCmd func github.com/redis/go-redis/v9.UniversalClient.SMembers(ctx Context, key string) *redis.StringSliceCmd func github.com/redis/go-redis/v9.UniversalClient.SMembersMap(ctx Context, key string) *redis.StringStructMapCmd func github.com/redis/go-redis/v9.UniversalClient.SMIsMember(ctx Context, key string, members ...interface{}) *redis.BoolSliceCmd func github.com/redis/go-redis/v9.UniversalClient.SMove(ctx Context, source, destination string, member interface{}) *redis.BoolCmd func github.com/redis/go-redis/v9.UniversalClient.Sort(ctx Context, key string, sort *redis.Sort) *redis.StringSliceCmd func github.com/redis/go-redis/v9.UniversalClient.SortInterfaces(ctx Context, key string, sort *redis.Sort) *redis.SliceCmd func github.com/redis/go-redis/v9.UniversalClient.SortRO(ctx Context, key string, sort *redis.Sort) *redis.StringSliceCmd func github.com/redis/go-redis/v9.UniversalClient.SortStore(ctx Context, key, store string, sort *redis.Sort) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.SPop(ctx Context, key string) *redis.StringCmd func github.com/redis/go-redis/v9.UniversalClient.SPopN(ctx Context, key string, count int64) *redis.StringSliceCmd func github.com/redis/go-redis/v9.UniversalClient.SPublish(ctx Context, channel string, message interface{}) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.SRandMember(ctx Context, key string) *redis.StringCmd func github.com/redis/go-redis/v9.UniversalClient.SRandMemberN(ctx Context, key string, count int64) *redis.StringSliceCmd func github.com/redis/go-redis/v9.UniversalClient.SRem(ctx Context, key string, members ...interface{}) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.SScan(ctx Context, key string, cursor uint64, match string, count int64) *redis.ScanCmd func github.com/redis/go-redis/v9.UniversalClient.SSubscribe(ctx Context, channels ...string) *redis.PubSub func github.com/redis/go-redis/v9.UniversalClient.StrLen(ctx Context, key string) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.Subscribe(ctx Context, channels ...string) *redis.PubSub func github.com/redis/go-redis/v9.UniversalClient.SUnion(ctx Context, keys ...string) *redis.StringSliceCmd func github.com/redis/go-redis/v9.UniversalClient.SUnionStore(ctx Context, destination string, keys ...string) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.Time(ctx Context) *redis.TimeCmd func github.com/redis/go-redis/v9.UniversalClient.Touch(ctx Context, keys ...string) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.TTL(ctx Context, key string) *redis.DurationCmd func github.com/redis/go-redis/v9.UniversalClient.TxPipelined(ctx Context, fn func(redis.Pipeliner) error) ([]redis.Cmder, error) func github.com/redis/go-redis/v9.UniversalClient.Type(ctx Context, key string) *redis.StatusCmd func github.com/redis/go-redis/v9.UniversalClient.Unlink(ctx Context, keys ...string) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.Watch(ctx Context, fn func(*redis.Tx) error, keys ...string) error func github.com/redis/go-redis/v9.UniversalClient.XAck(ctx Context, stream, group string, ids ...string) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.XAdd(ctx Context, a *redis.XAddArgs) *redis.StringCmd func github.com/redis/go-redis/v9.UniversalClient.XAutoClaim(ctx Context, a *redis.XAutoClaimArgs) *redis.XAutoClaimCmd func github.com/redis/go-redis/v9.UniversalClient.XAutoClaimJustID(ctx Context, a *redis.XAutoClaimArgs) *redis.XAutoClaimJustIDCmd func github.com/redis/go-redis/v9.UniversalClient.XClaim(ctx Context, a *redis.XClaimArgs) *redis.XMessageSliceCmd func github.com/redis/go-redis/v9.UniversalClient.XClaimJustID(ctx Context, a *redis.XClaimArgs) *redis.StringSliceCmd func github.com/redis/go-redis/v9.UniversalClient.XDel(ctx Context, stream string, ids ...string) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.XGroupCreate(ctx Context, stream, group, start string) *redis.StatusCmd func github.com/redis/go-redis/v9.UniversalClient.XGroupCreateConsumer(ctx Context, stream, group, consumer string) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.XGroupCreateMkStream(ctx Context, stream, group, start string) *redis.StatusCmd func github.com/redis/go-redis/v9.UniversalClient.XGroupDelConsumer(ctx Context, stream, group, consumer string) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.XGroupDestroy(ctx Context, stream, group string) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.XGroupSetID(ctx Context, stream, group, start string) *redis.StatusCmd func github.com/redis/go-redis/v9.UniversalClient.XInfoConsumers(ctx Context, key string, group string) *redis.XInfoConsumersCmd func github.com/redis/go-redis/v9.UniversalClient.XInfoGroups(ctx Context, key string) *redis.XInfoGroupsCmd func github.com/redis/go-redis/v9.UniversalClient.XInfoStream(ctx Context, key string) *redis.XInfoStreamCmd func github.com/redis/go-redis/v9.UniversalClient.XInfoStreamFull(ctx Context, key string, count int) *redis.XInfoStreamFullCmd func github.com/redis/go-redis/v9.UniversalClient.XLen(ctx Context, stream string) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.XPending(ctx Context, stream, group string) *redis.XPendingCmd func github.com/redis/go-redis/v9.UniversalClient.XPendingExt(ctx Context, a *redis.XPendingExtArgs) *redis.XPendingExtCmd func github.com/redis/go-redis/v9.UniversalClient.XRange(ctx Context, stream, start, stop string) *redis.XMessageSliceCmd func github.com/redis/go-redis/v9.UniversalClient.XRangeN(ctx Context, stream, start, stop string, count int64) *redis.XMessageSliceCmd func github.com/redis/go-redis/v9.UniversalClient.XRead(ctx Context, a *redis.XReadArgs) *redis.XStreamSliceCmd func github.com/redis/go-redis/v9.UniversalClient.XReadGroup(ctx Context, a *redis.XReadGroupArgs) *redis.XStreamSliceCmd func github.com/redis/go-redis/v9.UniversalClient.XReadStreams(ctx Context, streams ...string) *redis.XStreamSliceCmd func github.com/redis/go-redis/v9.UniversalClient.XRevRange(ctx Context, stream string, start, stop string) *redis.XMessageSliceCmd func github.com/redis/go-redis/v9.UniversalClient.XRevRangeN(ctx Context, stream string, start, stop string, count int64) *redis.XMessageSliceCmd func github.com/redis/go-redis/v9.UniversalClient.XTrimMaxLen(ctx Context, key string, maxLen int64) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.XTrimMaxLenApprox(ctx Context, key string, maxLen, limit int64) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.XTrimMinID(ctx Context, key string, minID string) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.XTrimMinIDApprox(ctx Context, key string, minID string, limit int64) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.ZAdd(ctx Context, key string, members ...redis.Z) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.ZAddArgs(ctx Context, key string, args redis.ZAddArgs) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.ZAddArgsIncr(ctx Context, key string, args redis.ZAddArgs) *redis.FloatCmd func github.com/redis/go-redis/v9.UniversalClient.ZAddGT(ctx Context, key string, members ...redis.Z) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.ZAddLT(ctx Context, key string, members ...redis.Z) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.ZAddNX(ctx Context, key string, members ...redis.Z) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.ZAddXX(ctx Context, key string, members ...redis.Z) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.ZCard(ctx Context, key string) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.ZCount(ctx Context, key, min, max string) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.ZDiff(ctx Context, keys ...string) *redis.StringSliceCmd func github.com/redis/go-redis/v9.UniversalClient.ZDiffStore(ctx Context, destination string, keys ...string) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.ZDiffWithScores(ctx Context, keys ...string) *redis.ZSliceCmd func github.com/redis/go-redis/v9.UniversalClient.ZIncrBy(ctx Context, key string, increment float64, member string) *redis.FloatCmd func github.com/redis/go-redis/v9.UniversalClient.ZInter(ctx Context, store *redis.ZStore) *redis.StringSliceCmd func github.com/redis/go-redis/v9.UniversalClient.ZInterCard(ctx Context, limit int64, keys ...string) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.ZInterStore(ctx Context, destination string, store *redis.ZStore) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.ZInterWithScores(ctx Context, store *redis.ZStore) *redis.ZSliceCmd func github.com/redis/go-redis/v9.UniversalClient.ZLexCount(ctx Context, key, min, max string) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.ZMPop(ctx Context, order string, count int64, keys ...string) *redis.ZSliceWithKeyCmd func github.com/redis/go-redis/v9.UniversalClient.ZMScore(ctx Context, key string, members ...string) *redis.FloatSliceCmd func github.com/redis/go-redis/v9.UniversalClient.ZPopMax(ctx Context, key string, count ...int64) *redis.ZSliceCmd func github.com/redis/go-redis/v9.UniversalClient.ZPopMin(ctx Context, key string, count ...int64) *redis.ZSliceCmd func github.com/redis/go-redis/v9.UniversalClient.ZRandMember(ctx Context, key string, count int) *redis.StringSliceCmd func github.com/redis/go-redis/v9.UniversalClient.ZRandMemberWithScores(ctx Context, key string, count int) *redis.ZSliceCmd func github.com/redis/go-redis/v9.UniversalClient.ZRange(ctx Context, key string, start, stop int64) *redis.StringSliceCmd func github.com/redis/go-redis/v9.UniversalClient.ZRangeArgs(ctx Context, z redis.ZRangeArgs) *redis.StringSliceCmd func github.com/redis/go-redis/v9.UniversalClient.ZRangeArgsWithScores(ctx Context, z redis.ZRangeArgs) *redis.ZSliceCmd func github.com/redis/go-redis/v9.UniversalClient.ZRangeByLex(ctx Context, key string, opt *redis.ZRangeBy) *redis.StringSliceCmd func github.com/redis/go-redis/v9.UniversalClient.ZRangeByScore(ctx Context, key string, opt *redis.ZRangeBy) *redis.StringSliceCmd func github.com/redis/go-redis/v9.UniversalClient.ZRangeByScoreWithScores(ctx Context, key string, opt *redis.ZRangeBy) *redis.ZSliceCmd func github.com/redis/go-redis/v9.UniversalClient.ZRangeStore(ctx Context, dst string, z redis.ZRangeArgs) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.ZRangeWithScores(ctx Context, key string, start, stop int64) *redis.ZSliceCmd func github.com/redis/go-redis/v9.UniversalClient.ZRank(ctx Context, key, member string) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.ZRem(ctx Context, key string, members ...interface{}) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.ZRemRangeByLex(ctx Context, key, min, max string) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.ZRemRangeByRank(ctx Context, key string, start, stop int64) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.ZRemRangeByScore(ctx Context, key, min, max string) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.ZRevRange(ctx Context, key string, start, stop int64) *redis.StringSliceCmd func github.com/redis/go-redis/v9.UniversalClient.ZRevRangeByLex(ctx Context, key string, opt *redis.ZRangeBy) *redis.StringSliceCmd func github.com/redis/go-redis/v9.UniversalClient.ZRevRangeByScore(ctx Context, key string, opt *redis.ZRangeBy) *redis.StringSliceCmd func github.com/redis/go-redis/v9.UniversalClient.ZRevRangeByScoreWithScores(ctx Context, key string, opt *redis.ZRangeBy) *redis.ZSliceCmd func github.com/redis/go-redis/v9.UniversalClient.ZRevRangeWithScores(ctx Context, key string, start, stop int64) *redis.ZSliceCmd func github.com/redis/go-redis/v9.UniversalClient.ZRevRank(ctx Context, key, member string) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.ZScan(ctx Context, key string, cursor uint64, match string, count int64) *redis.ScanCmd func github.com/redis/go-redis/v9.UniversalClient.ZScore(ctx Context, key, member string) *redis.FloatCmd func github.com/redis/go-redis/v9.UniversalClient.ZUnion(ctx Context, store redis.ZStore) *redis.StringSliceCmd func github.com/redis/go-redis/v9.UniversalClient.ZUnionStore(ctx Context, dest string, store *redis.ZStore) *redis.IntCmd func github.com/redis/go-redis/v9.UniversalClient.ZUnionWithScores(ctx Context, store redis.ZStore) *redis.ZSliceCmd func github.com/redis/go-redis/v9/internal.Sleep(ctx Context, dur time.Duration) error func github.com/redis/go-redis/v9/internal.Logging.Printf(ctx Context, format string, v ...interface{}) func github.com/redis/go-redis/v9/internal/pool.(*Conn).WithReader(ctx Context, timeout time.Duration, fn func(rd *proto.Reader) error) error func github.com/redis/go-redis/v9/internal/pool.(*Conn).WithWriter(ctx Context, timeout time.Duration, fn func(wr *proto.Writer) error) error func github.com/redis/go-redis/v9/internal/pool.(*ConnPool).Get(ctx Context) (*pool.Conn, error) func github.com/redis/go-redis/v9/internal/pool.(*ConnPool).NewConn(ctx Context) (*pool.Conn, error) func github.com/redis/go-redis/v9/internal/pool.(*ConnPool).Put(ctx Context, cn *pool.Conn) func github.com/redis/go-redis/v9/internal/pool.(*ConnPool).Remove(_ Context, cn *pool.Conn, reason error) func github.com/redis/go-redis/v9/internal/pool.Pooler.Get(Context) (*pool.Conn, error) func github.com/redis/go-redis/v9/internal/pool.Pooler.NewConn(Context) (*pool.Conn, error) func github.com/redis/go-redis/v9/internal/pool.Pooler.Put(Context, *pool.Conn) func github.com/redis/go-redis/v9/internal/pool.Pooler.Remove(Context, *pool.Conn, error) func github.com/redis/go-redis/v9/internal/pool.(*SingleConnPool).Get(ctx Context) (*pool.Conn, error) func github.com/redis/go-redis/v9/internal/pool.(*SingleConnPool).NewConn(ctx Context) (*pool.Conn, error) func github.com/redis/go-redis/v9/internal/pool.(*SingleConnPool).Put(ctx Context, cn *pool.Conn) func github.com/redis/go-redis/v9/internal/pool.(*SingleConnPool).Remove(ctx Context, cn *pool.Conn, reason error) func github.com/redis/go-redis/v9/internal/pool.(*StickyConnPool).Get(ctx Context) (*pool.Conn, error) func github.com/redis/go-redis/v9/internal/pool.(*StickyConnPool).NewConn(ctx Context) (*pool.Conn, error) func github.com/redis/go-redis/v9/internal/pool.(*StickyConnPool).Put(ctx Context, cn *pool.Conn) func github.com/redis/go-redis/v9/internal/pool.(*StickyConnPool).Remove(ctx Context, cn *pool.Conn, reason error) func github.com/redis/go-redis/v9/internal/pool.(*StickyConnPool).Reset(ctx Context) error func github.com/reeflective/console.(*Console).StartContext(ctx Context) error func github.com/reeflective/console.(*Menu).RunCommandArgs(ctx Context, args []string) (err error) func github.com/reeflective/console.(*Menu).RunCommandLine(ctx Context, line string) (err error) func github.com/rsteube/carapace/third_party/golang.org/x/sys/execabs.CommandContext(ctx Context, name string, arg ...string) *exec.Cmd func github.com/sethvargo/go-envconfig.MustProcess[T](ctx Context, i T, mus ...envconfig.Mutator) T func github.com/sethvargo/go-envconfig.Process(ctx Context, i any, mus ...envconfig.Mutator) error func github.com/sethvargo/go-envconfig.ProcessWith(ctx Context, c *envconfig.Config) error func github.com/sethvargo/go-envconfig.Mutator.EnvMutate(ctx Context, originalKey, resolvedKey, originalValue, currentValue string) (newValue string, stop bool, err error) func github.com/sethvargo/go-envconfig.MutatorFunc.EnvMutate(ctx Context, originalKey, resolvedKey, originalValue, currentValue string) (newValue string, stop bool, err error) func github.com/shirou/gopsutil/v3/cpu.CountsWithContext(ctx Context, logical bool) (int, error) func github.com/shirou/gopsutil/v3/cpu.InfoWithContext(ctx Context) ([]cpu.InfoStat, error) func github.com/shirou/gopsutil/v3/cpu.PercentWithContext(ctx Context, interval time.Duration, percpu bool) ([]float64, error) func github.com/shirou/gopsutil/v3/cpu.TimesWithContext(ctx Context, percpu bool) ([]cpu.TimesStat, error) func github.com/shirou/gopsutil/v3/internal/common.BootTimeWithContext(ctx Context, enableCache bool) (uint64, error) func github.com/shirou/gopsutil/v3/internal/common.CallLsofWithContext(ctx Context, invoke common.Invoker, pid int32, args ...string) ([]string, error) func github.com/shirou/gopsutil/v3/internal/common.CallPgrepWithContext(ctx Context, invoke common.Invoker, pid int32) ([]int32, error) func github.com/shirou/gopsutil/v3/internal/common.GetEnvWithContext(ctx Context, key string, dfault string, combineWith ...string) string func github.com/shirou/gopsutil/v3/internal/common.GetOSReleaseWithContext(ctx Context) (platform string, version string, err error) func github.com/shirou/gopsutil/v3/internal/common.HostDevWithContext(ctx Context, combineWith ...string) string func github.com/shirou/gopsutil/v3/internal/common.HostEtcWithContext(ctx Context, combineWith ...string) string func github.com/shirou/gopsutil/v3/internal/common.HostProcMountInfoWithContext(ctx Context, combineWith ...string) string func github.com/shirou/gopsutil/v3/internal/common.HostProcWithContext(ctx Context, combineWith ...string) string func github.com/shirou/gopsutil/v3/internal/common.HostRootWithContext(ctx Context, combineWith ...string) string func github.com/shirou/gopsutil/v3/internal/common.HostRunWithContext(ctx Context, combineWith ...string) string func github.com/shirou/gopsutil/v3/internal/common.HostSysWithContext(ctx Context, combineWith ...string) string func github.com/shirou/gopsutil/v3/internal/common.HostVarWithContext(ctx Context, combineWith ...string) string func github.com/shirou/gopsutil/v3/internal/common.NumProcsWithContext(ctx Context) (uint64, error) func github.com/shirou/gopsutil/v3/internal/common.Sleep(ctx Context, interval time.Duration) error func github.com/shirou/gopsutil/v3/internal/common.VirtualizationWithContext(ctx Context) (string, string, error) func github.com/shirou/gopsutil/v3/internal/common.FakeInvoke.CommandWithContext(ctx Context, name string, arg ...string) ([]byte, error) func github.com/shirou/gopsutil/v3/internal/common.Invoke.CommandWithContext(ctx Context, name string, arg ...string) ([]byte, error) func github.com/shirou/gopsutil/v3/internal/common.Invoker.CommandWithContext(Context, string, ...string) ([]byte, error) func github.com/shirou/gopsutil/v3/mem.SwapDevicesWithContext(ctx Context) ([]*mem.SwapDevice, error) func github.com/shirou/gopsutil/v3/mem.SwapMemoryWithContext(ctx Context) (*mem.SwapMemoryStat, error) func github.com/shirou/gopsutil/v3/mem.VirtualMemoryExWithContext(ctx Context) (*mem.VirtualMemoryExStat, error) func github.com/shirou/gopsutil/v3/mem.VirtualMemoryWithContext(ctx Context) (*mem.VirtualMemoryStat, error) func github.com/shirou/gopsutil/v3/net.ConnectionsMaxWithContext(ctx Context, kind string, max int) ([]net.ConnectionStat, error) func github.com/shirou/gopsutil/v3/net.ConnectionsMaxWithoutUidsWithContext(ctx Context, kind string, max int) ([]net.ConnectionStat, error) func github.com/shirou/gopsutil/v3/net.ConnectionsPidMaxWithContext(ctx Context, kind string, pid int32, max int) ([]net.ConnectionStat, error) func github.com/shirou/gopsutil/v3/net.ConnectionsPidMaxWithoutUidsWithContext(ctx Context, kind string, pid int32, max int) ([]net.ConnectionStat, error) func github.com/shirou/gopsutil/v3/net.ConnectionsPidWithContext(ctx Context, kind string, pid int32) ([]net.ConnectionStat, error) func github.com/shirou/gopsutil/v3/net.ConnectionsPidWithoutUidsWithContext(ctx Context, kind string, pid int32) ([]net.ConnectionStat, error) func github.com/shirou/gopsutil/v3/net.ConnectionsWithContext(ctx Context, kind string) ([]net.ConnectionStat, error) func github.com/shirou/gopsutil/v3/net.ConnectionsWithoutUidsWithContext(ctx Context, kind string) ([]net.ConnectionStat, error) func github.com/shirou/gopsutil/v3/net.ConntrackStatsWithContext(ctx Context, percpu bool) ([]net.ConntrackStat, error) func github.com/shirou/gopsutil/v3/net.FilterCountersWithContext(ctx Context) ([]net.FilterStat, error) func github.com/shirou/gopsutil/v3/net.InterfacesWithContext(ctx Context) (net.InterfaceStatList, error) func github.com/shirou/gopsutil/v3/net.IOCountersByFileWithContext(ctx Context, pernic bool, filename string) ([]net.IOCountersStat, error) func github.com/shirou/gopsutil/v3/net.IOCountersWithContext(ctx Context, pernic bool) ([]net.IOCountersStat, error) func github.com/shirou/gopsutil/v3/net.PidsWithContext(ctx Context) ([]int32, error) func github.com/shirou/gopsutil/v3/net.ProtoCountersWithContext(ctx Context, protocols []string) ([]net.ProtoCountersStat, error) func github.com/shirou/gopsutil/v3/net.ReverseWithContext(ctx Context, s []byte) []byte func github.com/shirou/gopsutil/v3/process.NewProcessWithContext(ctx Context, pid int32) (*process.Process, error) func github.com/shirou/gopsutil/v3/process.PidExistsWithContext(ctx Context, pid int32) (bool, error) func github.com/shirou/gopsutil/v3/process.PidsWithContext(ctx Context) ([]int32, error) func github.com/shirou/gopsutil/v3/process.ProcessesWithContext(ctx Context) ([]*process.Process, error) func github.com/shirou/gopsutil/v3/process.(*Process).BackgroundWithContext(ctx Context) (bool, error) func github.com/shirou/gopsutil/v3/process.(*Process).ChildrenWithContext(ctx Context) ([]*process.Process, error) func github.com/shirou/gopsutil/v3/process.(*Process).CmdlineSliceWithContext(ctx Context) ([]string, error) func github.com/shirou/gopsutil/v3/process.(*Process).CmdlineWithContext(ctx Context) (string, error) func github.com/shirou/gopsutil/v3/process.(*Process).ConnectionsMaxWithContext(ctx Context, max int) ([]net.ConnectionStat, error) func github.com/shirou/gopsutil/v3/process.(*Process).ConnectionsWithContext(ctx Context) ([]net.ConnectionStat, error) func github.com/shirou/gopsutil/v3/process.(*Process).CPUAffinityWithContext(ctx Context) ([]int32, error) func github.com/shirou/gopsutil/v3/process.(*Process).CPUPercentWithContext(ctx Context) (float64, error) func github.com/shirou/gopsutil/v3/process.(*Process).CreateTimeWithContext(ctx Context) (int64, error) func github.com/shirou/gopsutil/v3/process.(*Process).CwdWithContext(ctx Context) (string, error) func github.com/shirou/gopsutil/v3/process.(*Process).EnvironWithContext(ctx Context) ([]string, error) func github.com/shirou/gopsutil/v3/process.(*Process).ExeWithContext(ctx Context) (string, error) func github.com/shirou/gopsutil/v3/process.(*Process).ForegroundWithContext(ctx Context) (bool, error) func github.com/shirou/gopsutil/v3/process.(*Process).GidsWithContext(ctx Context) ([]int32, error) func github.com/shirou/gopsutil/v3/process.(*Process).GroupsWithContext(ctx Context) ([]int32, error) func github.com/shirou/gopsutil/v3/process.(*Process).IOCountersWithContext(ctx Context) (*process.IOCountersStat, error) func github.com/shirou/gopsutil/v3/process.(*Process).IOniceWithContext(ctx Context) (int32, error) func github.com/shirou/gopsutil/v3/process.(*Process).IsRunningWithContext(ctx Context) (bool, error) func github.com/shirou/gopsutil/v3/process.(*Process).KillWithContext(ctx Context) error func github.com/shirou/gopsutil/v3/process.(*Process).MemoryInfoExWithContext(ctx Context) (*process.MemoryInfoExStat, error) func github.com/shirou/gopsutil/v3/process.(*Process).MemoryInfoWithContext(ctx Context) (*process.MemoryInfoStat, error) func github.com/shirou/gopsutil/v3/process.(*Process).MemoryMapsWithContext(ctx Context, grouped bool) (*[]process.MemoryMapsStat, error) func github.com/shirou/gopsutil/v3/process.(*Process).MemoryPercentWithContext(ctx Context) (float32, error) func github.com/shirou/gopsutil/v3/process.(*Process).NameWithContext(ctx Context) (string, error) func github.com/shirou/gopsutil/v3/process.(*Process).NiceWithContext(ctx Context) (int32, error) func github.com/shirou/gopsutil/v3/process.(*Process).NumCtxSwitchesWithContext(ctx Context) (*process.NumCtxSwitchesStat, error) func github.com/shirou/gopsutil/v3/process.(*Process).NumFDsWithContext(ctx Context) (int32, error) func github.com/shirou/gopsutil/v3/process.(*Process).NumThreadsWithContext(ctx Context) (int32, error) func github.com/shirou/gopsutil/v3/process.(*Process).OpenFilesWithContext(ctx Context) ([]process.OpenFilesStat, error) func github.com/shirou/gopsutil/v3/process.(*Process).PageFaultsWithContext(ctx Context) (*process.PageFaultsStat, error) func github.com/shirou/gopsutil/v3/process.(*Process).ParentWithContext(ctx Context) (*process.Process, error) func github.com/shirou/gopsutil/v3/process.(*Process).PercentWithContext(ctx Context, interval time.Duration) (float64, error) func github.com/shirou/gopsutil/v3/process.(*Process).PpidWithContext(ctx Context) (int32, error) func github.com/shirou/gopsutil/v3/process.(*Process).ResumeWithContext(ctx Context) error func github.com/shirou/gopsutil/v3/process.(*Process).RlimitUsageWithContext(ctx Context, gatherUsed bool) ([]process.RlimitStat, error) func github.com/shirou/gopsutil/v3/process.(*Process).RlimitWithContext(ctx Context) ([]process.RlimitStat, error) func github.com/shirou/gopsutil/v3/process.(*Process).SendSignalWithContext(ctx Context, sig syscall.Signal) error func github.com/shirou/gopsutil/v3/process.(*Process).StatusWithContext(ctx Context) ([]string, error) func github.com/shirou/gopsutil/v3/process.(*Process).SuspendWithContext(ctx Context) error func github.com/shirou/gopsutil/v3/process.(*Process).TerminalWithContext(ctx Context) (string, error) func github.com/shirou/gopsutil/v3/process.(*Process).TerminateWithContext(ctx Context) error func github.com/shirou/gopsutil/v3/process.(*Process).TgidWithContext(ctx Context) (int32, error) func github.com/shirou/gopsutil/v3/process.(*Process).ThreadsWithContext(ctx Context) (map[int32]*cpu.TimesStat, error) func github.com/shirou/gopsutil/v3/process.(*Process).TimesWithContext(ctx Context) (*cpu.TimesStat, error) func github.com/shirou/gopsutil/v3/process.(*Process).UidsWithContext(ctx Context) ([]int32, error) func github.com/shirou/gopsutil/v3/process.(*Process).UsernameWithContext(ctx Context) (string, error) func github.com/spf13/cobra.(*Command).ExecuteContext(ctx Context) error func github.com/spf13/cobra.(*Command).ExecuteContextC(ctx Context) (*cobra.Command, error) func github.com/spf13/cobra.(*Command).SetContext(ctx Context) func github.com/tetratelabs/wazero.NewRuntime(ctx Context) wazero.Runtime func github.com/tetratelabs/wazero.NewRuntimeWithConfig(ctx Context, rConfig wazero.RuntimeConfig) wazero.Runtime func github.com/tetratelabs/wazero.CompilationCache.Close(Context) error func github.com/tetratelabs/wazero.CompiledModule.Close(Context) error func github.com/tetratelabs/wazero.HostModuleBuilder.Compile(Context) (wazero.CompiledModule, error) func github.com/tetratelabs/wazero.HostModuleBuilder.Instantiate(Context) (api.Module, error) func github.com/tetratelabs/wazero.Runtime.Close(Context) error func github.com/tetratelabs/wazero.Runtime.CloseWithExitCode(ctx Context, exitCode uint32) error func github.com/tetratelabs/wazero.Runtime.CompileModule(ctx Context, binary []byte) (wazero.CompiledModule, error) func github.com/tetratelabs/wazero.Runtime.Instantiate(ctx Context, source []byte) (api.Module, error) func github.com/tetratelabs/wazero.Runtime.InstantiateModule(ctx Context, compiled wazero.CompiledModule, config wazero.ModuleConfig) (api.Module, error) func github.com/tetratelabs/wazero.Runtime.InstantiateWithConfig(ctx Context, source []byte, config wazero.ModuleConfig) (api.Module, error) func github.com/tetratelabs/wazero/api.Closer.Close(Context) error func github.com/tetratelabs/wazero/api.Function.Call(ctx Context, params ...uint64) ([]uint64, error) func github.com/tetratelabs/wazero/api.Function.CallWithStack(ctx Context, stack []uint64) error func github.com/tetratelabs/wazero/api.GoFunc.Call(ctx Context, stack []uint64) func github.com/tetratelabs/wazero/api.GoFunction.Call(ctx Context, stack []uint64) func github.com/tetratelabs/wazero/api.GoModuleFunc.Call(ctx Context, mod api.Module, stack []uint64) func github.com/tetratelabs/wazero/api.GoModuleFunction.Call(ctx Context, mod api.Module, stack []uint64) func github.com/tetratelabs/wazero/api.Module.Close(Context) error func github.com/tetratelabs/wazero/api.Module.CloseWithExitCode(ctx Context, exitCode uint32) error func github.com/tetratelabs/wazero/experimental.GetSnapshotter(ctx Context) experimental.Snapshotter func github.com/tetratelabs/wazero/experimental.WithCloseNotifier(ctx Context, notifier experimental.CloseNotifier) Context func github.com/tetratelabs/wazero/experimental.WithFunctionListenerFactory(ctx Context, factory experimental.FunctionListenerFactory) Context func github.com/tetratelabs/wazero/experimental.WithImportResolver(ctx Context, resolver experimental.ImportResolver) Context func github.com/tetratelabs/wazero/experimental.WithMemoryAllocator(ctx Context, allocator experimental.MemoryAllocator) Context func github.com/tetratelabs/wazero/experimental.WithSnapshotter(ctx Context) Context func github.com/tetratelabs/wazero/experimental.CloseNotifier.CloseNotify(ctx Context, exitCode uint32) func github.com/tetratelabs/wazero/experimental.CloseNotifyFunc.CloseNotify(ctx Context, exitCode uint32) func github.com/tetratelabs/wazero/experimental.FunctionListener.Abort(ctx Context, mod api.Module, def api.FunctionDefinition, err error) func github.com/tetratelabs/wazero/experimental.FunctionListener.After(ctx Context, mod api.Module, def api.FunctionDefinition, results []uint64) func github.com/tetratelabs/wazero/experimental.FunctionListener.Before(ctx Context, mod api.Module, def api.FunctionDefinition, params []uint64, stackIterator experimental.StackIterator) func github.com/tetratelabs/wazero/experimental.FunctionListenerFunc.Abort(Context, api.Module, api.FunctionDefinition, error) func github.com/tetratelabs/wazero/experimental.FunctionListenerFunc.After(Context, api.Module, api.FunctionDefinition, []uint64) func github.com/tetratelabs/wazero/experimental.FunctionListenerFunc.Before(ctx Context, mod api.Module, def api.FunctionDefinition, params []uint64, stackIterator experimental.StackIterator) func github.com/tetratelabs/wazero/experimental.InternalModule.Close(Context) error func github.com/tetratelabs/wazero/experimental.InternalModule.CloseWithExitCode(ctx Context, exitCode uint32) error func github.com/tetratelabs/wazero/internal/engine/interpreter.NewEngine(_ Context, enabledFeatures api.CoreFeatures, _ filecache.Cache) wasm.Engine func github.com/tetratelabs/wazero/internal/engine/wazevo.NewEngine(ctx Context, _ api.CoreFeatures, fc filecache.Cache) wasm.Engine func github.com/tetratelabs/wazero/internal/engine/wazevo/backend.NewCompiler(ctx Context, mach backend.Machine, builder ssa.Builder) backend.Compiler func github.com/tetratelabs/wazero/internal/engine/wazevo/backend.Compiler.Compile(ctx Context) (_ []byte, _ []backend.RelocationInfo, _ error) func github.com/tetratelabs/wazero/internal/engine/wazevo/backend.Compiler.Finalize(ctx Context) error func github.com/tetratelabs/wazero/internal/engine/wazevo/backend.Machine.Encode(ctx Context) error func github.com/tetratelabs/wazero/internal/engine/wazevo/wazevoapi.DeterministicCompilationVerifierGetRandomizedLocalFunctionIndex(ctx Context, index int) int func github.com/tetratelabs/wazero/internal/engine/wazevo/wazevoapi.DeterministicCompilationVerifierRandomizeIndexes(ctx Context) func github.com/tetratelabs/wazero/internal/engine/wazevo/wazevoapi.GetCurrentFunctionIndex(ctx Context) int func github.com/tetratelabs/wazero/internal/engine/wazevo/wazevoapi.GetCurrentFunctionName(ctx Context) string func github.com/tetratelabs/wazero/internal/engine/wazevo/wazevoapi.NewDeterministicCompilationVerifierContext(ctx Context, localFunctions int) Context func github.com/tetratelabs/wazero/internal/engine/wazevo/wazevoapi.PrintEnabledIndex(ctx Context) bool func github.com/tetratelabs/wazero/internal/engine/wazevo/wazevoapi.SetCurrentFunctionName(ctx Context, index int, functionName string) Context func github.com/tetratelabs/wazero/internal/engine/wazevo/wazevoapi.VerifyOrSetDeterministicCompilationContextValue(ctx Context, scope string, newValue string) func github.com/tetratelabs/wazero/internal/wasm.Engine.CompileModule(ctx Context, module *wasm.Module, listeners []experimental.FunctionListener, ensureTermination bool) error func github.com/tetratelabs/wazero/internal/wasm.(*ModuleInstance).Close(ctx Context) (err error) func github.com/tetratelabs/wazero/internal/wasm.(*ModuleInstance).CloseModuleOnCanceledOrTimeout(ctx Context) CancelFunc func github.com/tetratelabs/wazero/internal/wasm.(*ModuleInstance).CloseWithCtxErr(ctx Context) func github.com/tetratelabs/wazero/internal/wasm.(*ModuleInstance).CloseWithExitCode(ctx Context, exitCode uint32) (err error) func github.com/tetratelabs/wazero/internal/wasm.(*Store).CloseWithExitCode(ctx Context, exitCode uint32) error func github.com/tetratelabs/wazero/internal/wasm.(*Store).Instantiate(ctx Context, module *wasm.Module, name string, sys *internalsys.Context, typeIDs []wasm.FunctionTypeID) (*wasm.ModuleInstance, error) func github.com/thanos-io/objstore.DownloadDir(ctx Context, logger log.Logger, bkt objstore.BucketReader, originalSrc, src, dst string, options ...objstore.DownloadOption) error func github.com/thanos-io/objstore.DownloadFile(ctx Context, logger log.Logger, bkt objstore.BucketReader, src, dst string) (err error) func github.com/thanos-io/objstore.EmptyBucket(t testing.TB, ctx Context, bkt objstore.Bucket) func github.com/thanos-io/objstore.UploadDir(ctx Context, logger log.Logger, bkt objstore.Bucket, srcdir, dstdir string, options ...objstore.UploadOption) error func github.com/thanos-io/objstore.UploadFile(ctx Context, logger log.Logger, bkt objstore.Bucket, src, dst string) error func github.com/thanos-io/objstore.Bucket.Attributes(ctx Context, name string) (objstore.ObjectAttributes, error) func github.com/thanos-io/objstore.Bucket.Delete(ctx Context, name string) error func github.com/thanos-io/objstore.Bucket.Exists(ctx Context, name string) (bool, error) func github.com/thanos-io/objstore.Bucket.Get(ctx Context, name string) (io.ReadCloser, error) func github.com/thanos-io/objstore.Bucket.GetRange(ctx Context, name string, off, length int64) (io.ReadCloser, error) func github.com/thanos-io/objstore.Bucket.Iter(ctx Context, dir string, f func(string) error, options ...objstore.IterOption) error func github.com/thanos-io/objstore.Bucket.Upload(ctx Context, name string, r io.Reader) error func github.com/thanos-io/objstore.BucketReader.Attributes(ctx Context, name string) (objstore.ObjectAttributes, error) func github.com/thanos-io/objstore.BucketReader.Exists(ctx Context, name string) (bool, error) func github.com/thanos-io/objstore.BucketReader.Get(ctx Context, name string) (io.ReadCloser, error) func github.com/thanos-io/objstore.BucketReader.GetRange(ctx Context, name string, off, length int64) (io.ReadCloser, error) func github.com/thanos-io/objstore.BucketReader.Iter(ctx Context, dir string, f func(string) error, options ...objstore.IterOption) error func github.com/thanos-io/objstore.(*InMemBucket).Attributes(_ Context, name string) (objstore.ObjectAttributes, error) func github.com/thanos-io/objstore.(*InMemBucket).Delete(_ Context, name string) error func github.com/thanos-io/objstore.(*InMemBucket).Exists(_ Context, name string) (bool, error) func github.com/thanos-io/objstore.(*InMemBucket).Get(_ Context, name string) (io.ReadCloser, error) func github.com/thanos-io/objstore.(*InMemBucket).GetRange(_ Context, name string, off, length int64) (io.ReadCloser, error) func github.com/thanos-io/objstore.(*InMemBucket).Iter(_ Context, dir string, f func(string) error, options ...objstore.IterOption) error func github.com/thanos-io/objstore.(*InMemBucket).Upload(_ Context, name string, r io.Reader) error func github.com/thanos-io/objstore.InstrumentedBucket.Attributes(ctx Context, name string) (objstore.ObjectAttributes, error) func github.com/thanos-io/objstore.InstrumentedBucket.Delete(ctx Context, name string) error func github.com/thanos-io/objstore.InstrumentedBucket.Exists(ctx Context, name string) (bool, error) func github.com/thanos-io/objstore.InstrumentedBucket.Get(ctx Context, name string) (io.ReadCloser, error) func github.com/thanos-io/objstore.InstrumentedBucket.GetRange(ctx Context, name string, off, length int64) (io.ReadCloser, error) func github.com/thanos-io/objstore.InstrumentedBucket.Iter(ctx Context, dir string, f func(string) error, options ...objstore.IterOption) error func github.com/thanos-io/objstore.InstrumentedBucket.Upload(ctx Context, name string, r io.Reader) error func github.com/thanos-io/objstore.InstrumentedBucketReader.Attributes(ctx Context, name string) (objstore.ObjectAttributes, error) func github.com/thanos-io/objstore.InstrumentedBucketReader.Exists(ctx Context, name string) (bool, error) func github.com/thanos-io/objstore.InstrumentedBucketReader.Get(ctx Context, name string) (io.ReadCloser, error) func github.com/thanos-io/objstore.InstrumentedBucketReader.GetRange(ctx Context, name string, off, length int64) (io.ReadCloser, error) func github.com/thanos-io/objstore.InstrumentedBucketReader.Iter(ctx Context, dir string, f func(string) error, options ...objstore.IterOption) error func github.com/thanos-io/objstore.PrefixedBucket.Attributes(ctx Context, name string) (objstore.ObjectAttributes, error) func github.com/thanos-io/objstore.(*PrefixedBucket).Delete(ctx Context, name string) error func github.com/thanos-io/objstore.(*PrefixedBucket).Exists(ctx Context, name string) (bool, error) func github.com/thanos-io/objstore.(*PrefixedBucket).Get(ctx Context, name string) (io.ReadCloser, error) func github.com/thanos-io/objstore.(*PrefixedBucket).GetRange(ctx Context, name string, off int64, length int64) (io.ReadCloser, error) func github.com/thanos-io/objstore.(*PrefixedBucket).Iter(ctx Context, dir string, f func(string) error, options ...objstore.IterOption) error func github.com/thanos-io/objstore.(*PrefixedBucket).Upload(ctx Context, name string, r io.Reader) error func go.opentelemetry.io/otel/baggage.ContextWithBaggage(parent Context, b baggage.Baggage) Context func go.opentelemetry.io/otel/baggage.ContextWithoutBaggage(parent Context) Context func go.opentelemetry.io/otel/baggage.FromContext(ctx Context) baggage.Baggage func go.opentelemetry.io/otel/exporters/otlp/otlptrace.New(ctx Context, client otlptrace.Client) (*otlptrace.Exporter, error) func go.opentelemetry.io/otel/exporters/otlp/otlptrace.Client.Start(ctx Context) error func go.opentelemetry.io/otel/exporters/otlp/otlptrace.Client.Stop(ctx Context) error func go.opentelemetry.io/otel/exporters/otlp/otlptrace.Client.UploadTraces(ctx Context, protoSpans []*tracepb.ResourceSpans) error func go.opentelemetry.io/otel/exporters/otlp/otlptrace.(*Exporter).ExportSpans(ctx Context, ss []tracesdk.ReadOnlySpan) error func go.opentelemetry.io/otel/exporters/otlp/otlptrace.(*Exporter).Shutdown(ctx Context) error func go.opentelemetry.io/otel/exporters/otlp/otlptrace.(*Exporter).Start(ctx Context) error func go.opentelemetry.io/otel/exporters/otlp/otlptrace/otlptracegrpc.New(ctx Context, opts ...otlptracegrpc.Option) (*otlptrace.Exporter, error) func go.opentelemetry.io/otel/internal/baggage.ContextWithGetHook(parent Context, hook baggage.GetHookFunc) Context func go.opentelemetry.io/otel/internal/baggage.ContextWithList(parent Context, list baggage.List) Context func go.opentelemetry.io/otel/internal/baggage.ContextWithSetHook(parent Context, hook baggage.SetHookFunc) Context func go.opentelemetry.io/otel/internal/baggage.ListFromContext(ctx Context) baggage.List func go.opentelemetry.io/otel/log.Logger.Emit(ctx Context, record log.Record) func go.opentelemetry.io/otel/log.Logger.Enabled(ctx Context, param log.EnabledParameters) bool func go.opentelemetry.io/otel/log/noop.Logger.Emit(Context, log.Record) func go.opentelemetry.io/otel/log/noop.Logger.Enabled(Context, log.EnabledParameters) bool func go.opentelemetry.io/otel/metric.Float64Counter.Add(ctx Context, incr float64, options ...metric.AddOption) func go.opentelemetry.io/otel/metric.Float64Gauge.Record(ctx Context, value float64, options ...metric.RecordOption) func go.opentelemetry.io/otel/metric.Float64Histogram.Record(ctx Context, incr float64, options ...metric.RecordOption) func go.opentelemetry.io/otel/metric.Float64UpDownCounter.Add(ctx Context, incr float64, options ...metric.AddOption) func go.opentelemetry.io/otel/metric.Int64Counter.Add(ctx Context, incr int64, options ...metric.AddOption) func go.opentelemetry.io/otel/metric.Int64Gauge.Record(ctx Context, value int64, options ...metric.RecordOption) func go.opentelemetry.io/otel/metric.Int64Histogram.Record(ctx Context, incr int64, options ...metric.RecordOption) func go.opentelemetry.io/otel/metric.Int64UpDownCounter.Add(ctx Context, incr int64, options ...metric.AddOption) func go.opentelemetry.io/otel/metric/noop.Float64Counter.Add(Context, float64, ...metric.AddOption) func go.opentelemetry.io/otel/metric/noop.Float64Gauge.Record(Context, float64, ...metric.RecordOption) func go.opentelemetry.io/otel/metric/noop.Float64Histogram.Record(Context, float64, ...metric.RecordOption) func go.opentelemetry.io/otel/metric/noop.Float64UpDownCounter.Add(Context, float64, ...metric.AddOption) func go.opentelemetry.io/otel/metric/noop.Int64Counter.Add(Context, int64, ...metric.AddOption) func go.opentelemetry.io/otel/metric/noop.Int64Gauge.Record(Context, int64, ...metric.RecordOption) func go.opentelemetry.io/otel/metric/noop.Int64Histogram.Record(Context, int64, ...metric.RecordOption) func go.opentelemetry.io/otel/metric/noop.Int64UpDownCounter.Add(Context, int64, ...metric.AddOption) func go.opentelemetry.io/otel/propagation.Baggage.Extract(parent Context, carrier propagation.TextMapCarrier) Context func go.opentelemetry.io/otel/propagation.Baggage.Inject(ctx Context, carrier propagation.TextMapCarrier) func go.opentelemetry.io/otel/propagation.TextMapPropagator.Extract(ctx Context, carrier propagation.TextMapCarrier) Context func go.opentelemetry.io/otel/propagation.TextMapPropagator.Inject(ctx Context, carrier propagation.TextMapCarrier) func go.opentelemetry.io/otel/propagation.TraceContext.Extract(ctx Context, carrier propagation.TextMapCarrier) Context func go.opentelemetry.io/otel/propagation.TraceContext.Inject(ctx Context, carrier propagation.TextMapCarrier) func go.opentelemetry.io/otel/sdk/log.(*BatchProcessor).ForceFlush(ctx Context) error func go.opentelemetry.io/otel/sdk/log.(*BatchProcessor).OnEmit(_ Context, r *log.Record) error func go.opentelemetry.io/otel/sdk/log.(*BatchProcessor).Shutdown(ctx Context) error func go.opentelemetry.io/otel/sdk/log.Exporter.Export(ctx Context, records []log.Record) error func go.opentelemetry.io/otel/sdk/log.Exporter.ForceFlush(ctx Context) error func go.opentelemetry.io/otel/sdk/log.Exporter.Shutdown(ctx Context) error func go.opentelemetry.io/otel/sdk/log.FilterProcessor.Enabled(ctx Context, param log.EnabledParameters) bool func go.opentelemetry.io/otel/sdk/log.(*LoggerProvider).ForceFlush(ctx Context) error func go.opentelemetry.io/otel/sdk/log.(*LoggerProvider).Shutdown(ctx Context) error func go.opentelemetry.io/otel/sdk/log.Processor.ForceFlush(ctx Context) error func go.opentelemetry.io/otel/sdk/log.Processor.OnEmit(ctx Context, record *log.Record) error func go.opentelemetry.io/otel/sdk/log.Processor.Shutdown(ctx Context) error func go.opentelemetry.io/otel/sdk/log.(*SimpleProcessor).ForceFlush(ctx Context) error func go.opentelemetry.io/otel/sdk/log.(*SimpleProcessor).OnEmit(ctx Context, r *log.Record) error func go.opentelemetry.io/otel/sdk/log.(*SimpleProcessor).Shutdown(ctx Context) error func go.opentelemetry.io/otel/sdk/resource.Detect(ctx Context, detectors ...resource.Detector) (*resource.Resource, error) func go.opentelemetry.io/otel/sdk/resource.New(ctx Context, opts ...resource.Option) (*resource.Resource, error) func go.opentelemetry.io/otel/sdk/resource.Detector.Detect(ctx Context) (*resource.Resource, error) func go.opentelemetry.io/otel/sdk/trace.IDGenerator.NewIDs(ctx Context) (trace.TraceID, trace.SpanID) func go.opentelemetry.io/otel/sdk/trace.IDGenerator.NewSpanID(ctx Context, traceID trace.TraceID) trace.SpanID func go.opentelemetry.io/otel/sdk/trace.SpanExporter.ExportSpans(ctx Context, spans []trace.ReadOnlySpan) error func go.opentelemetry.io/otel/sdk/trace.SpanExporter.Shutdown(ctx Context) error func go.opentelemetry.io/otel/sdk/trace.SpanProcessor.ForceFlush(ctx Context) error func go.opentelemetry.io/otel/sdk/trace.SpanProcessor.OnStart(parent Context, s trace.ReadWriteSpan) func go.opentelemetry.io/otel/sdk/trace.SpanProcessor.Shutdown(ctx Context) error func go.opentelemetry.io/otel/sdk/trace.(*TracerProvider).ForceFlush(ctx Context) error func go.opentelemetry.io/otel/sdk/trace.(*TracerProvider).Shutdown(ctx Context) error func go.opentelemetry.io/otel/semconv/v1.37.0/otelconv.SDKExporterLogExported.Add(ctx Context, incr int64, attrs ...attribute.KeyValue) func go.opentelemetry.io/otel/semconv/v1.37.0/otelconv.SDKExporterLogExported.AddSet(ctx Context, incr int64, set attribute.Set) func go.opentelemetry.io/otel/semconv/v1.37.0/otelconv.SDKExporterLogInflight.Add(ctx Context, incr int64, attrs ...attribute.KeyValue) func go.opentelemetry.io/otel/semconv/v1.37.0/otelconv.SDKExporterLogInflight.AddSet(ctx Context, incr int64, set attribute.Set) func go.opentelemetry.io/otel/semconv/v1.37.0/otelconv.SDKExporterMetricDataPointExported.Add(ctx Context, incr int64, attrs ...attribute.KeyValue) func go.opentelemetry.io/otel/semconv/v1.37.0/otelconv.SDKExporterMetricDataPointExported.AddSet(ctx Context, incr int64, set attribute.Set) func go.opentelemetry.io/otel/semconv/v1.37.0/otelconv.SDKExporterMetricDataPointInflight.Add(ctx Context, incr int64, attrs ...attribute.KeyValue) func go.opentelemetry.io/otel/semconv/v1.37.0/otelconv.SDKExporterMetricDataPointInflight.AddSet(ctx Context, incr int64, set attribute.Set) func go.opentelemetry.io/otel/semconv/v1.37.0/otelconv.SDKExporterOperationDuration.Record(ctx Context, val float64, attrs ...attribute.KeyValue) func go.opentelemetry.io/otel/semconv/v1.37.0/otelconv.SDKExporterOperationDuration.RecordSet(ctx Context, val float64, set attribute.Set) func go.opentelemetry.io/otel/semconv/v1.37.0/otelconv.SDKExporterSpanExported.Add(ctx Context, incr int64, attrs ...attribute.KeyValue) func go.opentelemetry.io/otel/semconv/v1.37.0/otelconv.SDKExporterSpanExported.AddSet(ctx Context, incr int64, set attribute.Set) func go.opentelemetry.io/otel/semconv/v1.37.0/otelconv.SDKExporterSpanInflight.Add(ctx Context, incr int64, attrs ...attribute.KeyValue) func go.opentelemetry.io/otel/semconv/v1.37.0/otelconv.SDKExporterSpanInflight.AddSet(ctx Context, incr int64, set attribute.Set) func go.opentelemetry.io/otel/semconv/v1.37.0/otelconv.SDKLogCreated.Add(ctx Context, incr int64, attrs ...attribute.KeyValue) func go.opentelemetry.io/otel/semconv/v1.37.0/otelconv.SDKLogCreated.AddSet(ctx Context, incr int64, set attribute.Set) func go.opentelemetry.io/otel/semconv/v1.37.0/otelconv.SDKMetricReaderCollectionDuration.Record(ctx Context, val float64, attrs ...attribute.KeyValue) func go.opentelemetry.io/otel/semconv/v1.37.0/otelconv.SDKMetricReaderCollectionDuration.RecordSet(ctx Context, val float64, set attribute.Set) func go.opentelemetry.io/otel/semconv/v1.37.0/otelconv.SDKProcessorLogProcessed.Add(ctx Context, incr int64, attrs ...attribute.KeyValue) func go.opentelemetry.io/otel/semconv/v1.37.0/otelconv.SDKProcessorLogProcessed.AddSet(ctx Context, incr int64, set attribute.Set) func go.opentelemetry.io/otel/semconv/v1.37.0/otelconv.SDKProcessorSpanProcessed.Add(ctx Context, incr int64, attrs ...attribute.KeyValue) func go.opentelemetry.io/otel/semconv/v1.37.0/otelconv.SDKProcessorSpanProcessed.AddSet(ctx Context, incr int64, set attribute.Set) func go.opentelemetry.io/otel/semconv/v1.37.0/otelconv.SDKSpanLive.Add(ctx Context, incr int64, attrs ...attribute.KeyValue) func go.opentelemetry.io/otel/semconv/v1.37.0/otelconv.SDKSpanLive.AddSet(ctx Context, incr int64, set attribute.Set) func go.opentelemetry.io/otel/semconv/v1.37.0/otelconv.SDKSpanStarted.Add(ctx Context, incr int64, attrs ...attribute.KeyValue) func go.opentelemetry.io/otel/semconv/v1.37.0/otelconv.SDKSpanStarted.AddSet(ctx Context, incr int64, set attribute.Set) func go.opentelemetry.io/otel/trace.ContextWithRemoteSpanContext(parent Context, rsc trace.SpanContext) Context func go.opentelemetry.io/otel/trace.ContextWithSpan(parent Context, span trace.Span) Context func go.opentelemetry.io/otel/trace.ContextWithSpanContext(parent Context, sc trace.SpanContext) Context func go.opentelemetry.io/otel/trace.LinkFromContext(ctx Context, attrs ...attribute.KeyValue) trace.Link func go.opentelemetry.io/otel/trace.SpanContextFromContext(ctx Context) trace.SpanContext func go.opentelemetry.io/otel/trace.SpanFromContext(ctx Context) trace.Span func go.opentelemetry.io/otel/trace.Tracer.Start(ctx Context, spanName string, opts ...trace.SpanStartOption) (Context, trace.Span) func go.opentelemetry.io/otel/trace/noop.Tracer.Start(ctx Context, _ string, _ ...trace.SpanStartOption) (Context, trace.Span) func go.opentelemetry.io/proto/otlp/collector/trace/v1.RegisterTraceServiceHandler(ctx Context, mux *runtime.ServeMux, conn *grpc.ClientConn) error func go.opentelemetry.io/proto/otlp/collector/trace/v1.RegisterTraceServiceHandlerClient(ctx Context, mux *runtime.ServeMux, client v1.TraceServiceClient) error func go.opentelemetry.io/proto/otlp/collector/trace/v1.RegisterTraceServiceHandlerFromEndpoint(ctx Context, mux *runtime.ServeMux, endpoint string, opts []grpc.DialOption) (err error) func go.opentelemetry.io/proto/otlp/collector/trace/v1.RegisterTraceServiceHandlerServer(ctx Context, mux *runtime.ServeMux, server v1.TraceServiceServer) error func go.opentelemetry.io/proto/otlp/collector/trace/v1.TraceServiceClient.Export(ctx Context, in *v1.ExportTraceServiceRequest, opts ...grpc.CallOption) (*v1.ExportTraceServiceResponse, error) func go.opentelemetry.io/proto/otlp/collector/trace/v1.TraceServiceServer.Export(Context, *v1.ExportTraceServiceRequest) (*v1.ExportTraceServiceResponse, error) func go.opentelemetry.io/proto/otlp/collector/trace/v1.UnimplementedTraceServiceServer.Export(Context, *v1.ExportTraceServiceRequest) (*v1.ExportTraceServiceResponse, error) func go.uber.org/fx.(*App).Start(ctx Context) (err error) func go.uber.org/fx.(*App).Stop(ctx Context) (err error) func go.uber.org/fx/fxevent.(*SlogLogger).UseContext(ctx Context) func go.uber.org/fx/internal/fxclock.Clock.WithTimeout(Context, time.Duration) (Context, CancelFunc) func go.uber.org/fx/internal/fxclock.(*Mock).WithTimeout(ctx Context, d time.Duration) (Context, CancelFunc) func go.uber.org/fx/internal/lifecycle.(*Lifecycle).Start(ctx Context) error func go.uber.org/fx/internal/lifecycle.(*Lifecycle).Stop(ctx Context) error func golang.org/x/crypto/ssh.(*Client).DialContext(ctx Context, n, addr string) (net.Conn, 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/httpcommon.EncodeHeaders(ctx Context, param httpcommon.EncodeHeadersParam, headerf func(name, value string)) (res httpcommon.EncodeHeadersResult, _ 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).DeviceAccessToken(ctx Context, da *oauth2.DeviceAuthResponse, opts ...oauth2.AuthCodeOption) (*oauth2.Token, error) func golang.org/x/oauth2.(*Config).DeviceAuth(ctx Context, opts ...oauth2.AuthCodeOption) (*oauth2.DeviceAuthResponse, error) 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/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, styleCache *internal.AuthStyleCache) (*internal.Token, error) func golang.org/x/sync/errgroup.WithContext(ctx Context) (*errgroup.Group, Context) func golang.org/x/time/rate.(*Limiter).Wait(ctx Context) (err error) func golang.org/x/time/rate.(*Limiter).WaitN(ctx Context, n int) (err error) func google.golang.org/grpc.ClientSupportedCompressors(ctx Context) ([]string, 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 any, 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.SetSendCompressor(ctx Context, name string) 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 any, 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 any, reply any, 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/credentials.ClientHandshakeInfoFromContext(ctx Context) credentials.ClientHandshakeInfo func google.golang.org/grpc/credentials.NewContextWithRequestInfo(ctx Context, ri credentials.RequestInfo) Context 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/health/grpc_health_v1.HealthClient.Check(ctx Context, in *grpc_health_v1.HealthCheckRequest, opts ...grpc.CallOption) (*grpc_health_v1.HealthCheckResponse, error) func google.golang.org/grpc/health/grpc_health_v1.HealthClient.List(ctx Context, in *grpc_health_v1.HealthListRequest, opts ...grpc.CallOption) (*grpc_health_v1.HealthListResponse, error) func google.golang.org/grpc/health/grpc_health_v1.HealthClient.Watch(ctx Context, in *grpc_health_v1.HealthCheckRequest, opts ...grpc.CallOption) (grpc.ServerStreamingClient[grpc_health_v1.HealthCheckResponse], error) func google.golang.org/grpc/health/grpc_health_v1.HealthServer.Check(Context, *grpc_health_v1.HealthCheckRequest) (*grpc_health_v1.HealthCheckResponse, error) func google.golang.org/grpc/health/grpc_health_v1.HealthServer.List(Context, *grpc_health_v1.HealthListRequest) (*grpc_health_v1.HealthListResponse, error) func google.golang.org/grpc/health/grpc_health_v1.UnimplementedHealthServer.Check(Context, *grpc_health_v1.HealthCheckRequest) (*grpc_health_v1.HealthCheckResponse, error) func google.golang.org/grpc/health/grpc_health_v1.UnimplementedHealthServer.List(Context, *grpc_health_v1.HealthListRequest) (*grpc_health_v1.HealthListResponse, error) func google.golang.org/grpc/internal/backoff.RunF(ctx Context, f func() error, backoff func(int) time.Duration) func google.golang.org/grpc/internal/binarylog.MethodLogger.Log(Context, binarylog.LogEntryConfig) func google.golang.org/grpc/internal/binarylog.(*TruncatingMethodLogger).Log(_ Context, c binarylog.LogEntryConfig) func google.golang.org/grpc/internal/credentials.ClientHandshakeInfoFromContext(ctx Context) any func google.golang.org/grpc/internal/credentials.NewClientHandshakeInfoContext(ctx Context, chi any) Context func google.golang.org/grpc/internal/grpcsync.NewCallbackSerializer(ctx Context) *grpcsync.CallbackSerializer func google.golang.org/grpc/internal/grpcsync.NewPubSub(ctx Context) *grpcsync.PubSub 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/resolver.ClientInterceptor.NewStream(ctx Context, ri resolver.RPCInfo, done func(), newStream func(ctx Context, done func()) (resolver.ClientStream, error)) (resolver.ClientStream, error) func google.golang.org/grpc/internal/resolver.ServerInterceptor.AllowRPC(ctx Context) error func google.golang.org/grpc/internal/resolver/dns/internal.NetResolver.LookupHost(ctx Context, host string) (addrs []string, err error) func google.golang.org/grpc/internal/resolver/dns/internal.NetResolver.LookupSRV(ctx Context, service, proto, name string) (cname string, addrs []*net.SRV, err error) func google.golang.org/grpc/internal/resolver/dns/internal.NetResolver.LookupTXT(ctx Context, name string) (txts []string, err error) func google.golang.org/grpc/internal/stats.GetLabels(ctx Context) *stats.Labels func google.golang.org/grpc/internal/stats.SetLabels(ctx Context, labels *stats.Labels) Context func google.golang.org/grpc/internal/transport.GetConnection(ctx Context) net.Conn func google.golang.org/grpc/internal/transport.NewHTTP2Client(connectCtx, ctx Context, addr resolver.Address, opts transport.ConnectOptions, onClose func(transport.GoAwayReason)) (_ transport.ClientTransport, err error) func google.golang.org/grpc/internal/transport.SetConnection(ctx Context, conn net.Conn) Context func google.golang.org/grpc/internal/transport.ClientTransport.NewStream(ctx Context, callHdr *transport.CallHdr) (*transport.ClientStream, error) func google.golang.org/grpc/internal/transport.(*ServerStream).SetContext(ctx Context) func google.golang.org/grpc/internal/transport.ServerTransport.HandleStreams(Context, func(*transport.ServerStream)) func google.golang.org/grpc/metadata.AppendToOutgoingContext(ctx Context, kv ...string) Context func google.golang.org/grpc/metadata.FromIncomingContext(ctx Context) (metadata.MD, bool) func google.golang.org/grpc/metadata.FromOutgoingContext(ctx Context) (metadata.MD, 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/metadata.ValueFromIncomingContext(ctx Context, key string) []string 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.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 gorm.io/datatypes.JSON.GormValue(ctx Context, db *gorm.DB) clause.Expr func gorm.io/datatypes.JSONMap.GormValue(ctx Context, db *gorm.DB) clause.Expr func gorm.io/datatypes.JSONSlice[T].GormValue(ctx Context, db *gorm.DB) clause.Expr func gorm.io/datatypes.JSONType[T].GormValue(ctx Context, db *gorm.DB) clause.Expr func gorm.io/gorm.ChainInterface.Count(ctx Context, column string) (result int64, err error) func gorm.io/gorm.ChainInterface.Delete(ctx Context) (rowsAffected int, err error) func gorm.io/gorm.ChainInterface.Find(ctx Context) ([]T, error) func gorm.io/gorm.ChainInterface.FindInBatches(ctx Context, batchSize int, fc func(data []T, batch int) error) error func gorm.io/gorm.ChainInterface.First(Context) (T, error) func gorm.io/gorm.ChainInterface.Last(ctx Context) (T, error) func gorm.io/gorm.ChainInterface.Row(ctx Context) *sql.Row func gorm.io/gorm.ChainInterface.Rows(ctx Context) (*sql.Rows, error) func gorm.io/gorm.ChainInterface.Scan(ctx Context, r interface{}) error func gorm.io/gorm.ChainInterface.Take(Context) (T, error) func gorm.io/gorm.ChainInterface.Update(ctx Context, name string, value any) (rowsAffected int, err error) func gorm.io/gorm.ChainInterface.Updates(ctx Context, t T) (rowsAffected int, err error) func gorm.io/gorm.ConnPool.ExecContext(ctx Context, query string, args ...interface{}) (sql.Result, error) func gorm.io/gorm.ConnPool.PrepareContext(ctx Context, query string) (*sql.Stmt, error) func gorm.io/gorm.ConnPool.QueryContext(ctx Context, query string, args ...interface{}) (*sql.Rows, error) func gorm.io/gorm.ConnPool.QueryRowContext(ctx Context, query string, args ...interface{}) *sql.Row func gorm.io/gorm.ConnPoolBeginner.BeginTx(ctx Context, opts *sql.TxOptions) (gorm.ConnPool, error) func gorm.io/gorm.CreateInterface.Count(ctx Context, column string) (result int64, err error) func gorm.io/gorm.CreateInterface.Create(ctx Context, r *T) error func gorm.io/gorm.CreateInterface.CreateInBatches(ctx Context, r *[]T, batchSize int) error func gorm.io/gorm.CreateInterface.Delete(ctx Context) (rowsAffected int, err error) func gorm.io/gorm.CreateInterface.Find(ctx Context) ([]T, error) func gorm.io/gorm.CreateInterface.FindInBatches(ctx Context, batchSize int, fc func(data []T, batch int) error) error func gorm.io/gorm.CreateInterface.First(Context) (T, error) func gorm.io/gorm.CreateInterface.Last(ctx Context) (T, error) func gorm.io/gorm.CreateInterface.Row(ctx Context) *sql.Row func gorm.io/gorm.CreateInterface.Rows(ctx Context) (*sql.Rows, error) func gorm.io/gorm.CreateInterface.Scan(ctx Context, r interface{}) error func gorm.io/gorm.CreateInterface.Take(Context) (T, error) func gorm.io/gorm.CreateInterface.Update(ctx Context, name string, value any) (rowsAffected int, err error) func gorm.io/gorm.CreateInterface.Updates(ctx Context, t T) (rowsAffected int, err error) func gorm.io/gorm.(*DB).WithContext(ctx Context) *gorm.DB func gorm.io/gorm.ExecInterface.Find(ctx Context) ([]T, error) func gorm.io/gorm.ExecInterface.FindInBatches(ctx Context, batchSize int, fc func(data []T, batch int) error) error func gorm.io/gorm.ExecInterface.First(Context) (T, error) func gorm.io/gorm.ExecInterface.Last(ctx Context) (T, error) func gorm.io/gorm.ExecInterface.Row(ctx Context) *sql.Row func gorm.io/gorm.ExecInterface.Rows(ctx Context) (*sql.Rows, error) func gorm.io/gorm.ExecInterface.Scan(ctx Context, r interface{}) error func gorm.io/gorm.ExecInterface.Take(Context) (T, error) func gorm.io/gorm.Interface.Count(ctx Context, column string) (result int64, err error) func gorm.io/gorm.Interface.Create(ctx Context, r *T) error func gorm.io/gorm.Interface.CreateInBatches(ctx Context, r *[]T, batchSize int) error func gorm.io/gorm.Interface.Delete(ctx Context) (rowsAffected int, err error) func gorm.io/gorm.Interface.Exec(ctx Context, sql string, values ...interface{}) error func gorm.io/gorm.Interface.Find(ctx Context) ([]T, error) func gorm.io/gorm.Interface.FindInBatches(ctx Context, batchSize int, fc func(data []T, batch int) error) error func gorm.io/gorm.Interface.First(Context) (T, error) func gorm.io/gorm.Interface.Last(ctx Context) (T, error) func gorm.io/gorm.Interface.Row(ctx Context) *sql.Row func gorm.io/gorm.Interface.Rows(ctx Context) (*sql.Rows, error) func gorm.io/gorm.Interface.Scan(ctx Context, r interface{}) error func gorm.io/gorm.Interface.Take(Context) (T, error) func gorm.io/gorm.Interface.Update(ctx Context, name string, value any) (rowsAffected int, err error) func gorm.io/gorm.Interface.Updates(ctx Context, t T) (rowsAffected int, err error) func gorm.io/gorm.ParamsFilter.ParamsFilter(ctx Context, sql string, params ...interface{}) (string, []interface{}) func gorm.io/gorm.(*PreparedStmtDB).BeginTx(ctx Context, opt *sql.TxOptions) (gorm.ConnPool, error) func gorm.io/gorm.(*PreparedStmtDB).ExecContext(ctx Context, query string, args ...interface{}) (result sql.Result, err error) func gorm.io/gorm.(*PreparedStmtDB).QueryContext(ctx Context, query string, args ...interface{}) (rows *sql.Rows, err error) func gorm.io/gorm.(*PreparedStmtDB).QueryRowContext(ctx Context, query string, args ...interface{}) *sql.Row func gorm.io/gorm.(*PreparedStmtTX).ExecContext(ctx Context, query string, args ...interface{}) (result sql.Result, err error) func gorm.io/gorm.(*PreparedStmtTX).QueryContext(ctx Context, query string, args ...interface{}) (rows *sql.Rows, err error) func gorm.io/gorm.(*PreparedStmtTX).QueryRowContext(ctx Context, query string, args ...interface{}) *sql.Row func gorm.io/gorm.SetCreateOrUpdateInterface.Create(ctx Context) error func gorm.io/gorm.SetCreateOrUpdateInterface.Update(ctx Context) (rowsAffected int, err error) func gorm.io/gorm.SetUpdateOnlyInterface.Update(ctx Context) (rowsAffected int, err error) func gorm.io/gorm.Tx.ExecContext(ctx Context, query string, args ...interface{}) (sql.Result, error) func gorm.io/gorm.Tx.PrepareContext(ctx Context, query string) (*sql.Stmt, error) func gorm.io/gorm.Tx.QueryContext(ctx Context, query string, args ...interface{}) (*sql.Rows, error) func gorm.io/gorm.Tx.QueryRowContext(ctx Context, query string, args ...interface{}) *sql.Row func gorm.io/gorm.Tx.StmtContext(ctx Context, stmt *sql.Stmt) *sql.Stmt func gorm.io/gorm.TxBeginner.BeginTx(ctx Context, opts *sql.TxOptions) (*sql.Tx, error) func gorm.io/gorm.Valuer.GormValue(Context, *gorm.DB) clause.Expr func gorm.io/gorm/internal/stmt_store.ConnPool.PrepareContext(ctx Context, query string) (*sql.Stmt, error) func gorm.io/gorm/internal/stmt_store.Store.New(ctx Context, key string, isTransaction bool, connPool stmt_store.ConnPool, locker sync.Locker) (*stmt_store.Stmt, error) func gorm.io/gorm/logger.Interface.Error(Context, string, ...interface{}) func gorm.io/gorm/logger.Interface.Info(Context, string, ...interface{}) func gorm.io/gorm/logger.Interface.Trace(ctx Context, begin time.Time, fc func() (sql string, rowsAffected int64), err error) func gorm.io/gorm/logger.Interface.Warn(Context, string, ...interface{}) func gorm.io/gorm/schema.GetIdentityFieldValuesMap(ctx Context, reflectValue reflect.Value, fields []*schema.Field) (map[string][]reflect.Value, [][]interface{}) func gorm.io/gorm/schema.GetIdentityFieldValuesMapFromValues(ctx Context, values []interface{}, fields []*schema.Field) (map[string][]reflect.Value, [][]interface{}) func gorm.io/gorm/schema.GetRelationsValues(ctx Context, reflectValue reflect.Value, rels []*schema.Relationship) (reflectResults reflect.Value) func gorm.io/gorm/schema.GobSerializer.Scan(ctx Context, field *schema.Field, dst reflect.Value, dbValue interface{}) (err error) func gorm.io/gorm/schema.GobSerializer.Value(ctx Context, field *schema.Field, dst reflect.Value, fieldValue interface{}) (interface{}, error) func gorm.io/gorm/schema.JSONSerializer.Scan(ctx Context, field *schema.Field, dst reflect.Value, dbValue interface{}) (err error) func gorm.io/gorm/schema.JSONSerializer.Value(ctx Context, field *schema.Field, dst reflect.Value, fieldValue interface{}) (interface{}, error) func gorm.io/gorm/schema.(*Relationship).ToQueryConditions(ctx Context, reflectValue reflect.Value) (conds []clause.Expression) func gorm.io/gorm/schema.SerializerInterface.Scan(ctx Context, field *schema.Field, dst reflect.Value, dbValue interface{}) error func gorm.io/gorm/schema.SerializerInterface.Value(ctx Context, field *schema.Field, dst reflect.Value, fieldValue interface{}) (interface{}, error) func gorm.io/gorm/schema.SerializerValuerInterface.Value(ctx Context, field *schema.Field, dst reflect.Value, fieldValue interface{}) (interface{}, error) func gorm.io/gorm/schema.UnixSecondSerializer.Scan(ctx Context, field *schema.Field, dst reflect.Value, dbValue interface{}) (err error) func gorm.io/gorm/schema.UnixSecondSerializer.Value(ctx Context, field *schema.Field, dst reflect.Value, fieldValue interface{}) (result interface{}, err error) func log/slog.DebugContext(ctx Context, msg string, args ...any) func log/slog.ErrorContext(ctx Context, msg string, args ...any) func log/slog.InfoContext(ctx Context, msg string, args ...any) func log/slog.Log(ctx Context, level slog.Level, msg string, args ...any) func log/slog.LogAttrs(ctx Context, level slog.Level, msg string, attrs ...slog.Attr) func log/slog.WarnContext(ctx Context, msg string, args ...any) func log/slog.Handler.Enabled(Context, slog.Level) bool func log/slog.Handler.Handle(Context, slog.Record) error func log/slog.(*JSONHandler).Enabled(_ Context, level slog.Level) bool func log/slog.(*JSONHandler).Handle(_ Context, r slog.Record) error func log/slog.(*Logger).DebugContext(ctx Context, msg string, args ...any) func log/slog.(*Logger).Enabled(ctx Context, level slog.Level) bool func log/slog.(*Logger).ErrorContext(ctx Context, msg string, args ...any) func log/slog.(*Logger).InfoContext(ctx Context, msg string, args ...any) func log/slog.(*Logger).Log(ctx Context, level slog.Level, msg string, args ...any) func log/slog.(*Logger).LogAttrs(ctx Context, level slog.Level, msg string, attrs ...slog.Attr) func log/slog.(*Logger).WarnContext(ctx Context, msg string, args ...any) func log/slog.(*TextHandler).Enabled(_ Context, level slog.Level) bool func log/slog.(*TextHandler).Handle(_ Context, r slog.Record) error 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) ([]string, error) func net.(*Resolver).LookupCNAME(ctx Context, host string) (string, 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).LookupNetIP(ctx Context, network, host string) ([]netip.Addr, 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) (string, []*net.SRV, 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/httptest.NewRequestWithContext(ctx Context, method, target string, body io.Reader) *http.Request func net/http/httptrace.ContextClientTrace(ctx Context) *httptrace.ClientTrace func net/http/httptrace.WithClientTrace(ctx Context, trace *httptrace.ClientTrace) Context func net/http/internal/httpcommon.EncodeHeaders(ctx Context, param httpcommon.EncodeHeadersParam, headerf func(name, value string)) (res httpcommon.EncodeHeadersResult, _ error) func os/exec.CommandContext(ctx Context, name string, arg ...string) *exec.Cmd func os/signal.NotifyContext(parent Context, signals ...os.Signal) (ctx Context, stop CancelFunc) func oss.terrastruct.com/d2/d2exporter.Export(ctx Context, g *d2graph.Graph, fontFamily *d2fonts.FontFamily) (*d2target.Diagram, error) func oss.terrastruct.com/d2/d2layouts.DefaultRouter(ctx Context, graph *d2graph.Graph, edges []*d2graph.Edge) error func oss.terrastruct.com/d2/d2layouts.LayoutNested(ctx Context, g *d2graph.Graph, graphInfo d2layouts.GraphInfo, coreLayout d2graph.LayoutGraph, edgeRouter d2graph.RouteEdges) error func oss.terrastruct.com/d2/d2layouts/d2dagrelayout.DefaultLayout(ctx Context, g *d2graph.Graph) (err error) func oss.terrastruct.com/d2/d2layouts/d2dagrelayout.Layout(ctx Context, g *d2graph.Graph, opts *d2dagrelayout.ConfigurableOpts) (err error) func oss.terrastruct.com/d2/d2layouts/d2elklayout.DefaultLayout(ctx Context, g *d2graph.Graph) (err error) func oss.terrastruct.com/d2/d2layouts/d2elklayout.Layout(ctx Context, g *d2graph.Graph, opts *d2elklayout.ConfigurableOpts) (err error) func oss.terrastruct.com/d2/d2layouts/d2grid.Layout(ctx Context, g *d2graph.Graph) error func oss.terrastruct.com/d2/d2layouts/d2near.Layout(ctx Context, g *d2graph.Graph, constantNearGraphs []*d2graph.Graph) error func oss.terrastruct.com/d2/d2layouts/d2sequence.Layout(ctx Context, g *d2graph.Graph, layout d2graph.LayoutGraph) error func oss.terrastruct.com/d2/d2lib.Compile(ctx Context, input string, compileOpts *d2lib.CompileOptions, renderOpts *d2svg.RenderOpts) (*d2target.Diagram, *d2graph.Graph, error) func oss.terrastruct.com/d2/d2lib.Parse(ctx Context, input string, compileOpts *d2lib.CompileOptions) (*d2ast.Map, error) func oss.terrastruct.com/d2/lib/jsrunner.JSRunner.WaitPromise(ctx Context, val jsrunner.JSValue) (interface{}, error) func oss.terrastruct.com/d2/lib/log.Debug(ctx Context, msg string, attrs ...slog.Attr) func oss.terrastruct.com/d2/lib/log.Error(ctx Context, msg string, attrs ...slog.Attr) func oss.terrastruct.com/d2/lib/log.Info(ctx Context, msg string, attrs ...slog.Attr) func oss.terrastruct.com/d2/lib/log.Leveled(ctx Context, level slog.Level) Context func oss.terrastruct.com/d2/lib/log.Warn(ctx Context, msg string, attrs ...slog.Attr) func oss.terrastruct.com/d2/lib/log.With(ctx Context, l *slog.Logger) Context func oss.terrastruct.com/d2/lib/log.WithDefault(ctx Context) Context func oss.terrastruct.com/d2/lib/log.WithTB(ctx Context, tb testing.TB) Context func oss.terrastruct.com/d2/lib/log.(*LevelHandler).Enabled(_ Context, level slog.Level) bool func oss.terrastruct.com/d2/lib/log.(*LevelHandler).Handle(ctx Context, r slog.Record) error func oss.terrastruct.com/d2/lib/log.(*PrettyHandler).Enabled(ctx Context, level slog.Level) bool func oss.terrastruct.com/d2/lib/log.(*PrettyHandler).Handle(ctx Context, r slog.Record) error 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 ...any) 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 12)
AfterFunc arranges to call f in its own goroutine after ctx is canceled. If ctx is already canceled, AfterFunc calls f immediately in its own goroutine. Multiple calls to AfterFunc on a context operate independently; one does not replace another. Calling the returned stop function stops the association of ctx with f. It returns true if the call stopped f from being run. If stop returns false, either the context is canceled and f has been started in its own goroutine; or f was already stopped. The stop function does not wait for f to complete before returning. If the caller needs to know whether f is completed, it must coordinate with f explicitly. If ctx has a "AfterFunc(func()) func() bool" method, AfterFunc will use it to schedule the call.
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.
Cause returns a non-nil error explaining why c was canceled. The first cancellation of c or one of its parents sets the cause. If that cancellation happened via a call to CancelCauseFunc(err), then [Cause] returns err. Otherwise Cause(c) returns the same value as c.Err(). Cause returns nil if c has not been canceled yet.
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 derived context that points to the parent context but has 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.
WithCancelCause behaves like [WithCancel] but returns a [CancelCauseFunc] instead of a [CancelFunc]. Calling cancel with a non-nil error (the "cause") records that error in ctx; it can then be retrieved using Cause(ctx). Calling cancel with nil sets the cause to Canceled. Example use: ctx, cancel := context.WithCancelCause(parent) cancel(myError) ctx.Err() // returns context.Canceled context.Cause(ctx) // returns myError
WithDeadline returns a derived context that points to the parent context but has 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.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.
WithDeadlineCause behaves like [WithDeadline] but also sets the cause of the returned Context when the deadline is exceeded. The returned [CancelFunc] does not set the cause.
WithoutCancel returns a derived context that points to the parent context and is not canceled when parent is canceled. The returned context returns no Deadline or Err, and its Done channel is nil. Calling [Cause] on the returned context returns nil.
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) }
WithTimeoutCause behaves like [WithTimeout] but also sets the cause of the returned Context when the timeout expires. The returned [CancelFunc] does not set the cause.
WithValue returns a derived context that points to the parent Context. In the derived context, 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 2)
Canceled is the error returned by [Context.Err] when the context is canceled for some reason other than its deadline passing.
DeadlineExceeded is the error returned by [Context.Err] when the context is canceled due to its deadline passing.