package context
Import Path
context (on go.dev )
Dependency Relation
imports 5 packages , and imported by 78 packages
Involved Source Files
#d context.go
Package context defines the Context type, which carries deadlines,
cancellation signals, and other request-scoped values across API boundaries
and between processes.
Incoming requests to a server should create a Context, and outgoing
calls to servers should accept a Context. The chain of function
calls between them must propagate the Context, optionally replacing
it with a derived Context created using WithCancel, WithDeadline,
WithTimeout, or WithValue. When a Context is canceled, all
Contexts derived from it are also canceled.
The WithCancel, WithDeadline, and WithTimeout functions take a
Context (the parent) and return a derived Context (the child) and a
CancelFunc. Calling the CancelFunc cancels the child and its
children, removes the parent's reference to the child, and stops
any associated timers. Failing to call the CancelFunc leaks the
child and its children until the parent is canceled or the timer
fires. The go vet tool checks that CancelFuncs are used on all
control-flow paths.
Programs that use Contexts should follow these rules to keep interfaces
consistent across packages and enable static analysis tools to check context
propagation:
Do not store Contexts inside a struct type; instead, pass a Context
explicitly to each function that needs it. The Context should be the first
parameter, typically named ctx:
func DoSomething(ctx context.Context, arg Arg) error {
// ... use ctx ...
}
Do not pass a nil Context, even if a function permits it. Pass context.TODO
if you are unsure about which Context to use.
Use context Values only for request-scoped data that transits processes and
APIs, not for passing optional parameters to functions.
The same Context may be passed to functions running in different goroutines;
Contexts are safe for simultaneous use by multiple goroutines.
See https://blog.golang.org/context for example code for a server that uses
Contexts.
Code Examples
WithCancel
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
}
}
}
WithDeadline
package main
import (
"context"
"fmt"
"time"
)
const shortDuration = 1 * time.Millisecond
func main() {
d := time.Now().Add(shortDuration)
ctx, cancel := context.WithDeadline(context.Background(), d)
// Even though ctx will be expired, it is good practice to call its
// cancellation function in any case. Failure to do so may keep the
// context and its parent alive longer than necessary.
defer cancel()
select {
case <-time.After(1 * time.Second):
fmt.Println("overslept")
case <-ctx.Done():
fmt.Println(ctx.Err())
}
}
WithTimeout
package main
import (
"context"
"fmt"
"time"
)
const shortDuration = 1 * time.Millisecond
func main() {
// Pass a context with a timeout to tell a blocking function that it
// should abandon its work after the timeout elapses.
ctx, cancel := context.WithTimeout(context.Background(), shortDuration)
defer cancel()
select {
case <-time.After(1 * time.Second):
fmt.Println("overslept")
case <-ctx.Done():
fmt.Println(ctx.Err()) // prints "context deadline exceeded"
}
}
WithValue
package main
import (
"context"
"fmt"
)
func main() {
type favContextKey string
f := func(ctx context.Context, k favContextKey) {
if v := ctx.Value(k); v != nil {
fmt.Println("found value:", v)
return
}
fmt.Println("key not found:", k)
}
k := favContextKey("language")
ctx := context.WithValue(context.Background(), k, "Go")
f(ctx, k)
f(ctx, favContextKey("color"))
}
Package-Level Type Names (total 9, in which 2 are exported)
/* sort exporteds by: alphabet | popularity */
type Context (interface)
A Context carries a deadline, a cancellation signal, and other values across
API boundaries.
Context's methods may be called by multiple goroutines simultaneously.
Methods (total 4, all are exported )
( Context) Deadline () (deadline time .Time , ok bool )
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.
( Context) Done () <-chan struct{}
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.
( Context) Err () error
If Done is not yet closed, Err returns nil.
If Done is closed, Err returns a non-nil error explaining why:
Canceled if the context was canceled
or DeadlineExceeded if the context's deadline passed.
After Err returns a non-nil error, successive calls to Err return the same error.
( Context) Value (key any ) any
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
}
Implemented By (at least 8, in which 1 are exported )
github.com/go-pg/pg/v10/internal.UndoneContext
/* 7+ unexporteds ... */ /* 7+ unexporteds: */
*cancelCtx
*emptyCtx
*timerCtx
*valueCtx
*github.com/aws/aws-sdk-go-v2/aws.suppressedContext
*github.com/aws/smithy-go/context.valueOnlyContext
*net.onlyValuesCtx
As Outputs Of (at least 109, in which 80 are exported )
func Background () Context
func TODO () Context
func WithCancel (parent Context ) (ctx Context , cancel CancelFunc )
func WithDeadline (parent Context , d time .Time ) (Context , CancelFunc )
func WithTimeout (parent Context , timeout time .Duration ) (Context , CancelFunc )
func WithValue (parent Context , key, val any ) Context
func crypto/tls.(*CertificateRequestInfo ).Context () Context
func crypto/tls.(*ClientHelloInfo ).Context () Context
func github.com/aws/aws-sdk-go-v2/aws/middleware.SetEndpointSource (ctx Context , value aws .EndpointSource ) Context
func github.com/aws/aws-sdk-go-v2/aws/middleware.SetPartitionID (ctx Context , value string ) Context
func github.com/aws/aws-sdk-go-v2/aws/middleware.SetServiceID (ctx Context , value string ) Context
func github.com/aws/aws-sdk-go-v2/aws/middleware.SetSigningCredentials (ctx Context , value aws .Credentials ) Context
func github.com/aws/aws-sdk-go-v2/aws/middleware.SetSigningName (ctx Context , value string ) Context
func github.com/aws/aws-sdk-go-v2/aws/middleware.SetSigningRegion (ctx Context , value string ) Context
func github.com/aws/aws-sdk-go-v2/aws/signer/v4.SetPayloadHash (ctx Context , hash string ) Context
func github.com/aws/aws-sdk-go-v2/service/internal/presigned-url.WithIsPresigning (ctx Context ) Context
func github.com/aws/aws-sdk-go-v2/service/internal/s3shared.SetClonedInputKey (ctx Context , value bool ) Context
func github.com/aws/aws-sdk-go-v2/service/s3/internal/customizations.SetSignerVersion (ctx Context , version string ) Context
func github.com/aws/smithy-go/context.WithPreserveExpiredValues (ctx Context , enable bool ) Context
func github.com/aws/smithy-go/context.WithSuppressCancel (ctx Context ) Context
func github.com/aws/smithy-go/middleware.ClearStackValues (ctx Context ) Context
func github.com/aws/smithy-go/middleware.SetLogger (ctx Context , logger logging .Logger ) Context
func github.com/aws/smithy-go/middleware.WithStackValue (ctx Context , key, value interface{}) Context
func github.com/aws/smithy-go/transport/http.DisableEndpointHostPrefix (ctx Context , value bool ) Context
func github.com/aws/smithy-go/transport/http.SetHostnameImmutable (ctx Context , value bool ) Context
func github.com/aws/smithy-go/transport/http.SetIsContentTypeDefaultValue (ctx Context , isDefault bool ) Context
func github.com/go-pg/migrations/v8.DB .Context () Context
func github.com/go-pg/pg/v10.BeforeDeleteHook .BeforeDelete (Context ) (Context , error )
func github.com/go-pg/pg/v10.BeforeInsertHook .BeforeInsert (Context ) (Context , error )
func github.com/go-pg/pg/v10.BeforeUpdateHook .BeforeUpdate (Context ) (Context , error )
func github.com/go-pg/pg/v10.(*Conn ).Context () Context
func github.com/go-pg/pg/v10.(*DB ).Context () Context
func github.com/go-pg/pg/v10.QueryHook .BeforeQuery (Context , *pg .QueryEvent ) (Context , error )
func github.com/go-pg/pg/v10.(*Tx ).Context () Context
func github.com/go-pg/pg/v10/orm.BeforeDeleteHook .BeforeDelete (Context ) (Context , error )
func github.com/go-pg/pg/v10/orm.BeforeInsertHook .BeforeInsert (Context ) (Context , error )
func github.com/go-pg/pg/v10/orm.BeforeUpdateHook .BeforeUpdate (Context ) (Context , error )
func github.com/go-pg/pg/v10/orm.DB .Context () Context
func github.com/go-pg/pg/v10/orm.Model .BeforeDelete (Context ) (Context , error )
func github.com/go-pg/pg/v10/orm.Model .BeforeInsert (Context ) (Context , error )
func github.com/go-pg/pg/v10/orm.Model .BeforeUpdate (Context ) (Context , error )
func github.com/go-pg/pg/v10/orm.TableModel .BeforeDelete (Context ) (Context , error )
func github.com/go-pg/pg/v10/orm.TableModel .BeforeInsert (Context ) (Context , error )
func github.com/go-pg/pg/v10/orm.TableModel .BeforeUpdate (Context ) (Context , error )
func github.com/golang/mock/gomock.WithContext (ctx Context , t gomock .TestReporter ) (*gomock .Controller , Context )
func github.com/robfig/cron/v3.(*Cron ).Stop () Context
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 golang.org/x/tools/internal/event.Detach (ctx Context ) Context
func golang.org/x/tools/internal/event.Label (ctx Context , labels ...label .Label ) Context
func golang.org/x/tools/internal/event.Start (ctx Context , name string , labels ...label .Label ) (Context , func())
func golang.org/x/tools/internal/event/core.Export (ctx Context , ev core .Event ) Context
func golang.org/x/tools/internal/event/core.ExportPair (ctx Context , begin, end core .Event ) (Context , func())
func golang.org/x/tools/internal/event/core.Metric1 (ctx Context , t1 label .Label ) Context
func golang.org/x/tools/internal/event/core.Metric2 (ctx Context , t1, t2 label .Label ) Context
func golang.org/x/tools/internal/event/core.Start1 (ctx Context , name string , t1 label .Label ) (Context , func())
func golang.org/x/tools/internal/event/core.Start2 (ctx Context , name string , t1, t2 label .Label ) (Context , func())
func google.golang.org/grpc.NewContextWithServerTransportStream (ctx Context , stream grpc .ServerTransportStream ) Context
func google.golang.org/grpc.ClientStream .Context () Context
func google.golang.org/grpc.ServerStream .Context () Context
func google.golang.org/grpc.Stream .Context () Context
func google.golang.org/grpc/internal/credentials.NewClientHandshakeInfoContext (ctx Context , chi interface{}) Context
func google.golang.org/grpc/internal/credentials.NewRequestInfoContext (ctx Context , ri interface{}) 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/transport.(*Stream ).Context () Context
func google.golang.org/grpc/metadata.AppendToOutgoingContext (ctx Context , kv ...string ) Context
func google.golang.org/grpc/metadata.NewIncomingContext (ctx Context , md metadata .MD ) Context
func google.golang.org/grpc/metadata.NewOutgoingContext (ctx Context , md metadata .MD ) Context
func google.golang.org/grpc/peer.NewContext (ctx Context , p *peer .Peer ) Context
func google.golang.org/grpc/stats.SetIncomingTags (ctx Context , b []byte ) Context
func google.golang.org/grpc/stats.SetIncomingTrace (ctx Context , b []byte ) Context
func google.golang.org/grpc/stats.SetTags (ctx Context , b []byte ) Context
func google.golang.org/grpc/stats.SetTrace (ctx Context , b []byte ) Context
func google.golang.org/grpc/stats.Handler .TagConn (Context , *stats .ConnTagInfo ) Context
func google.golang.org/grpc/stats.Handler .TagRPC (Context , *stats .RPCTagInfo ) Context
func net/http.(*Request ).Context () Context
func net/http/httptrace.WithClientTrace (ctx Context , trace *httptrace .ClientTrace ) Context
func runtime/pprof.WithLabels (ctx Context , labels pprof .LabelSet ) Context
func runtime/trace.NewTask (pctx Context , taskType string ) (ctx Context , task *trace .Task )
/* 29+ unexporteds ... */ /* 29+ unexporteds: */
func database/sql.(*Conn ).txCtx () Context
func database/sql.(*Tx ).txCtx () Context
func github.com/aws/aws-sdk-go-v2/aws/middleware.setOperationName (ctx Context , value string ) Context
func github.com/aws/aws-sdk-go-v2/aws/middleware.setRegion (ctx Context , value string ) Context
func github.com/aws/aws-sdk-go-v2/aws/protocol/eventstream/eventstreamapi.setInputStreamWriter (ctx Context , writeCloser io .WriteCloser ) Context
func github.com/aws/aws-sdk-go-v2/aws/retry.setRetryMetadata (ctx Context , metadata retry .retryMetadata ) Context
func github.com/aws/aws-sdk-go-v2/service/internal/checksum.setContextInputAlgorithm (ctx Context , value string ) Context
func github.com/aws/aws-sdk-go-v2/service/internal/checksum.setContextOutputValidationMode (ctx Context , value string ) Context
func github.com/aws/aws-sdk-go-v2/service/internal/s3shared.setARNResourceOnContext (ctx Context , value arn .ARN ) Context
func github.com/aws/aws-sdk-go-v2/service/s3/internal/customizations.buildAccessPointHostPrefix (ctx Context , req *http .Request , tv arn .AccessPointARN ) (Context , error )
func github.com/aws/aws-sdk-go-v2/service/s3/internal/customizations.buildAccessPointRequest (ctx Context , options customizations .accesspointOptions ) (Context , error )
func github.com/aws/aws-sdk-go-v2/service/s3/internal/customizations.buildMultiRegionAccessPointsRequest (ctx Context , options customizations .accesspointOptions ) (Context , error )
func github.com/aws/aws-sdk-go-v2/service/s3/internal/customizations.buildOutpostAccessPointRequest (ctx Context , options customizations .outpostAccessPointOptions ) (Context , error )
func github.com/aws/aws-sdk-go-v2/service/s3/internal/customizations.buildS3ObjectLambdaAccessPointRequest (ctx Context , options customizations .accesspointOptions ) (Context , error )
func github.com/aws/aws-sdk-go-v2/service/s3/internal/customizations.setBucketToRemoveOnContext (ctx Context , bucket string ) Context
func github.com/go-pg/pg/v10/orm.callBeforeDeleteHook (ctx Context , v reflect .Value ) (Context , error )
func github.com/go-pg/pg/v10/orm.callBeforeDeleteHookSlice (ctx Context , slice reflect .Value , ptr bool ) (Context , error )
func github.com/go-pg/pg/v10/orm.callBeforeInsertHook (ctx Context , v reflect .Value ) (Context , error )
func github.com/go-pg/pg/v10/orm.callBeforeInsertHookSlice (ctx Context , slice reflect .Value , ptr bool ) (Context , error )
func github.com/go-pg/pg/v10/orm.callBeforeUpdateHook (ctx Context , v reflect .Value ) (Context , error )
func github.com/go-pg/pg/v10/orm.callBeforeUpdateHookSlice (ctx Context , slice reflect .Value , ptr bool ) (Context , error )
func github.com/go-pg/pg/v10/orm.callHookSlice (ctx Context , slice reflect .Value , ptr bool , hook func(Context , reflect .Value ) (Context , error )) (Context , error )
func golang.org/x/net/http2.serverConnBaseContext (c net .Conn , opts *http2 .ServeConnOpts ) (ctx Context , cancel func())
func golang.org/x/net/http2.(*ServeConnOpts ).context () Context
func golang.org/x/tools/internal/event/core.deliver (ctx Context , exporter core .Exporter , ev core .Event ) Context
func google.golang.org/grpc.newContextWithRPCInfo (ctx Context , failfast bool , codec grpc .baseCodec , cp grpc .Compressor , comp encoding .Compressor ) Context
func google.golang.org/grpc/internal/transport.setConnection (ctx Context , conn net .Conn ) Context
func net.withUnexpiredValuesPreserved (lookupCtx Context ) Context
func net/http.http2serverConnBaseContext (c net .Conn , opts *http .http2ServeConnOpts ) (ctx Context , cancel func())
As Inputs Of (at least 713, in which 513 are exported )
func WithCancel (parent Context ) (ctx Context , cancel CancelFunc )
func WithDeadline (parent Context , d time .Time ) (Context , CancelFunc )
func WithTimeout (parent Context , timeout time .Duration ) (Context , CancelFunc )
func WithValue (parent Context , key, val any ) Context
func crypto/tls.(*Conn ).HandshakeContext (ctx Context ) error
func crypto/tls.(*Dialer ).DialContext (ctx Context , network, addr string ) (net .Conn , error )
func database/sql.(*Conn ).BeginTx (ctx Context , opts *sql .TxOptions ) (*sql .Tx , error )
func database/sql.(*Conn ).ExecContext (ctx Context , query string , args ...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/aws/aws-sdk-go-v2/aws.AnonymousCredentials .Retrieve (Context ) (aws .Credentials , error )
func github.com/aws/aws-sdk-go-v2/aws.(*CredentialsCache ).Retrieve (ctx Context ) (aws .Credentials , error )
func github.com/aws/aws-sdk-go-v2/aws.CredentialsProvider .Retrieve (ctx Context ) (aws .Credentials , error )
func github.com/aws/aws-sdk-go-v2/aws.CredentialsProviderFunc .Retrieve (ctx Context ) (aws .Credentials , error )
func github.com/aws/aws-sdk-go-v2/aws.HandleFailRefreshCredentialsCacheStrategy .HandleFailToRefresh (Context , aws .Credentials , error ) (aws .Credentials , error )
func github.com/aws/aws-sdk-go-v2/aws.NopRetryer .GetAttemptToken (Context ) (func(error ) error , error )
func github.com/aws/aws-sdk-go-v2/aws.NopRetryer .GetRetryToken (Context , error ) (func(error ) error , error )
func github.com/aws/aws-sdk-go-v2/aws.Retryer .GetRetryToken (ctx Context , opErr error ) (releaseToken func(error ) error , err error )
func github.com/aws/aws-sdk-go-v2/aws.RetryerV2 .GetAttemptToken (Context ) (func(error ) error , error )
func github.com/aws/aws-sdk-go-v2/aws.RetryerV2 .GetRetryToken (ctx Context , opErr error ) (releaseToken func(error ) error , err error )
func github.com/aws/aws-sdk-go-v2/aws/middleware.GetEndpointSource (ctx Context ) (v aws .EndpointSource )
func github.com/aws/aws-sdk-go-v2/aws/middleware.GetOperationName (ctx Context ) (v string )
func github.com/aws/aws-sdk-go-v2/aws/middleware.GetPartitionID (ctx Context ) string
func github.com/aws/aws-sdk-go-v2/aws/middleware.GetRegion (ctx Context ) (v string )
func github.com/aws/aws-sdk-go-v2/aws/middleware.GetServiceID (ctx Context ) (v string )
func github.com/aws/aws-sdk-go-v2/aws/middleware.GetSigningCredentials (ctx Context ) (v aws .Credentials )
func github.com/aws/aws-sdk-go-v2/aws/middleware.GetSigningName (ctx Context ) (v string )
func github.com/aws/aws-sdk-go-v2/aws/middleware.GetSigningRegion (ctx Context ) (v string )
func github.com/aws/aws-sdk-go-v2/aws/middleware.SetEndpointSource (ctx Context , value aws .EndpointSource ) Context
func github.com/aws/aws-sdk-go-v2/aws/middleware.SetPartitionID (ctx Context , value string ) Context
func github.com/aws/aws-sdk-go-v2/aws/middleware.SetServiceID (ctx Context , value string ) Context
func github.com/aws/aws-sdk-go-v2/aws/middleware.SetSigningCredentials (ctx Context , value aws .Credentials ) Context
func github.com/aws/aws-sdk-go-v2/aws/middleware.SetSigningName (ctx Context , value string ) Context
func github.com/aws/aws-sdk-go-v2/aws/middleware.SetSigningRegion (ctx Context , value string ) Context
func github.com/aws/aws-sdk-go-v2/aws/middleware.ClientRequestID .HandleBuild (ctx Context , in middleware .BuildInput , next middleware .BuildHandler ) (out middleware .BuildOutput , metadata middleware .Metadata , err error )
func github.com/aws/aws-sdk-go-v2/aws/middleware.RecordResponseTiming .HandleDeserialize (ctx Context , in middleware .DeserializeInput , next middleware .DeserializeHandler ) (out middleware .DeserializeOutput , metadata middleware .Metadata , err error )
func github.com/aws/aws-sdk-go-v2/aws/middleware.RegisterServiceMetadata .HandleInitialize (ctx Context , in middleware .InitializeInput , next middleware .InitializeHandler ) (out middleware .InitializeOutput , metadata middleware .Metadata , err error )
func github.com/aws/aws-sdk-go-v2/aws/protocol/eventstream/eventstreamapi.GetInputStreamWriter (ctx Context ) io .WriteCloser
func github.com/aws/aws-sdk-go-v2/aws/protocol/eventstream/eventstreamapi.(*InitializeStreamWriter ).HandleFinalize (ctx Context , in middleware .FinalizeInput , next middleware .FinalizeHandler ) (out middleware .FinalizeOutput , metadata middleware .Metadata , err error )
func github.com/aws/aws-sdk-go-v2/aws/ratelimit.(*TokenRateLimit ).GetToken (ctx Context , cost uint ) (func() error , error )
func github.com/aws/aws-sdk-go-v2/aws/retry.(*AdaptiveMode ).GetAttemptToken (ctx Context ) (func(error ) error , error )
func github.com/aws/aws-sdk-go-v2/aws/retry.(*AdaptiveMode ).GetRetryToken (ctx Context , opErr error ) (releaseToken func(error ) error , err error )
func github.com/aws/aws-sdk-go-v2/aws/retry.(*Attempt ).HandleFinalize (ctx Context , in smithymiddle .FinalizeInput , next smithymiddle .FinalizeHandler ) (out smithymiddle .FinalizeOutput , metadata smithymiddle .Metadata , err error )
func github.com/aws/aws-sdk-go-v2/aws/retry.MetricsHeader .HandleFinalize (ctx Context , in smithymiddle .FinalizeInput , next smithymiddle .FinalizeHandler ) (out smithymiddle .FinalizeOutput , metadata smithymiddle .Metadata , err error )
func github.com/aws/aws-sdk-go-v2/aws/retry.RateLimiter .GetToken (ctx Context , cost uint ) (releaseToken func() error , err error )
func github.com/aws/aws-sdk-go-v2/aws/retry.(*Standard ).GetAttemptToken (Context ) (func(error ) error , error )
func github.com/aws/aws-sdk-go-v2/aws/retry.(*Standard ).GetRetryToken (ctx Context , opErr error ) (func(error ) error , error )
func github.com/aws/aws-sdk-go-v2/aws/signer/v4.GetPayloadHash (ctx Context ) (v string )
func github.com/aws/aws-sdk-go-v2/aws/signer/v4.SetPayloadHash (ctx Context , hash string ) Context
func github.com/aws/aws-sdk-go-v2/aws/signer/v4.EventStreamSigner .GetSignature (ctx Context , headers, payload []byte , signingTime time .Time , optFns ...func(*v4 .StreamSignerOptions )) ([]byte , error )
func github.com/aws/aws-sdk-go-v2/aws/signer/v4.HTTPPresigner .PresignHTTP (ctx Context , credentials aws .Credentials , r *http .Request , payloadHash string , service string , region string , signingTime time .Time , optFns ...func(*v4 .SignerOptions )) (url string , signedHeader http .Header , err error )
func github.com/aws/aws-sdk-go-v2/aws/signer/v4.HTTPSigner .SignHTTP (ctx Context , credentials aws .Credentials , r *http .Request , payloadHash string , service string , region string , signingTime time .Time , optFns ...func(*v4 .SignerOptions )) error
func github.com/aws/aws-sdk-go-v2/aws/signer/v4.(*PresignHTTPRequestMiddleware ).HandleFinalize (ctx Context , in middleware .FinalizeInput , next middleware .FinalizeHandler ) (out middleware .FinalizeOutput , metadata middleware .Metadata , err error )
func github.com/aws/aws-sdk-go-v2/aws/signer/v4.(*Signer ).PresignHTTP (ctx Context , credentials aws .Credentials , r *http .Request , payloadHash string , service string , region string , signingTime time .Time , optFns ...func(*v4 .SignerOptions )) (signedURI string , signedHeaders http .Header , err error )
func github.com/aws/aws-sdk-go-v2/aws/signer/v4.Signer .SignHTTP (ctx Context , credentials aws .Credentials , r *http .Request , payloadHash string , service string , region string , signingTime time .Time , optFns ...func(options *v4 .SignerOptions )) error
func github.com/aws/aws-sdk-go-v2/aws/signer/v4.(*SignHTTPRequestMiddleware ).HandleFinalize (ctx Context , in middleware .FinalizeInput , next middleware .FinalizeHandler ) (out middleware .FinalizeOutput , metadata middleware .Metadata , err error )
func github.com/aws/aws-sdk-go-v2/aws/signer/v4.(*StreamSigner ).GetSignature (ctx Context , headers, payload []byte , signingTime time .Time , optFns ...func(*v4 .StreamSignerOptions )) ([]byte , error )
func github.com/aws/aws-sdk-go-v2/internal/configsources.ResolveEnableEndpointDiscovery (ctx Context , configs []interface{}) (value aws .EndpointDiscoveryEnableState , found bool , err error )
func github.com/aws/aws-sdk-go-v2/internal/configsources.ResolveUseDualStackEndpoint (ctx Context , configs []interface{}) (value aws .DualStackEndpointState , found bool , err error )
func github.com/aws/aws-sdk-go-v2/internal/configsources.ResolveUseFIPSEndpoint (ctx Context , configs []interface{}) (value aws .FIPSEndpointState , found bool , err error )
func github.com/aws/aws-sdk-go-v2/internal/configsources.EnableEndpointDiscoveryProvider .GetEnableEndpointDiscovery (ctx Context ) (value aws .EndpointDiscoveryEnableState , found bool , err error )
func github.com/aws/aws-sdk-go-v2/internal/configsources.UseDualStackEndpointProvider .GetUseDualStackEndpoint (Context ) (value aws .DualStackEndpointState , found bool , err error )
func github.com/aws/aws-sdk-go-v2/internal/configsources.UseFIPSEndpointProvider .GetUseFIPSEndpoint (Context ) (value aws .FIPSEndpointState , found bool , err error )
func github.com/aws/aws-sdk-go-v2/internal/v4a.CredentialsProvider .RetrievePrivateKey (Context ) (v4a .Credentials , error )
func github.com/aws/aws-sdk-go-v2/internal/v4a.HTTPPresigner .PresignHTTP (ctx Context , credentials v4a .Credentials , r *http .Request , payloadHash string , service string , regionSet []string , signingTime time .Time , optFns ...func(*v4a .SignerOptions )) (url string , signedHeader http .Header , err error )
func github.com/aws/aws-sdk-go-v2/internal/v4a.HTTPSigner .SignHTTP (ctx Context , credentials v4a .Credentials , r *http .Request , payloadHash string , service string , regionSet []string , signingTime time .Time , optfns ...func(*v4a .SignerOptions )) error
func github.com/aws/aws-sdk-go-v2/internal/v4a.(*PresignHTTPRequestMiddleware ).HandleFinalize (ctx Context , in middleware .FinalizeInput , next middleware .FinalizeHandler ) (out middleware .FinalizeOutput , metadata middleware .Metadata , err error )
func github.com/aws/aws-sdk-go-v2/internal/v4a.(*Signer ).PresignHTTP (ctx Context , credentials v4a .Credentials , r *http .Request , payloadHash string , service string , regionSet []string , signingTime time .Time , optFns ...func(*v4a .SignerOptions )) (signedURI string , signedHeaders http .Header , err error )
func github.com/aws/aws-sdk-go-v2/internal/v4a.(*Signer ).SignHTTP (ctx Context , credentials v4a .Credentials , r *http .Request , payloadHash string , service string , regionSet []string , signingTime time .Time , optFns ...func(*v4a .SignerOptions )) error
func github.com/aws/aws-sdk-go-v2/internal/v4a.(*SignHTTPRequestMiddleware ).HandleFinalize (ctx Context , in middleware .FinalizeInput , next middleware .FinalizeHandler ) (out middleware .FinalizeOutput , metadata middleware .Metadata , err error )
func github.com/aws/aws-sdk-go-v2/internal/v4a.(*SymmetricCredentialAdaptor ).Retrieve (ctx Context ) (aws .Credentials , error )
func github.com/aws/aws-sdk-go-v2/internal/v4a.(*SymmetricCredentialAdaptor ).RetrievePrivateKey (ctx Context ) (v4a .Credentials , error )
func github.com/aws/aws-sdk-go-v2/service/internal/accept-encoding.(*DecompressGzip ).HandleDeserialize (ctx Context , input middleware .DeserializeInput , next middleware .DeserializeHandler ) (output middleware .DeserializeOutput , metadata middleware .Metadata , err error )
func github.com/aws/aws-sdk-go-v2/service/internal/accept-encoding.(*DisableGzip ).HandleFinalize (ctx Context , input middleware .FinalizeInput , next middleware .FinalizeHandler ) (output middleware .FinalizeOutput , metadata middleware .Metadata , err error )
func github.com/aws/aws-sdk-go-v2/service/internal/accept-encoding.(*EnableGzip ).HandleFinalize (ctx Context , input middleware .FinalizeInput , next middleware .FinalizeHandler ) (output middleware .FinalizeOutput , metadata middleware .Metadata , err error )
func github.com/aws/aws-sdk-go-v2/service/internal/presigned-url.GetIsPresigning (ctx Context ) bool
func github.com/aws/aws-sdk-go-v2/service/internal/presigned-url.WithIsPresigning (ctx Context ) Context
func github.com/aws/aws-sdk-go-v2/service/internal/presigned-url.URLPresigner .PresignURL (ctx Context , srcRegion string , params interface{}) (*v4 .PresignedHTTPRequest , error )
func github.com/aws/aws-sdk-go-v2/service/internal/s3shared.GetARNResourceFromContext (ctx Context ) (arn .ARN , bool )
func github.com/aws/aws-sdk-go-v2/service/internal/s3shared.IsClonedInput (ctx Context ) bool
func github.com/aws/aws-sdk-go-v2/service/internal/s3shared.SetClonedInputKey (ctx Context , value bool ) Context
func github.com/aws/aws-sdk-go-v2/service/internal/s3shared.(*ARNLookup ).HandleInitialize (ctx Context , in middleware .InitializeInput , next middleware .InitializeHandler ) (out middleware .InitializeOutput , metadata middleware .Metadata , err error )
func github.com/aws/aws-sdk-go-v2/service/internal/s3shared.(*EnableDualstack ).HandleSerialize (ctx Context , in middleware .SerializeInput , next middleware .SerializeHandler ) (out middleware .SerializeOutput , metadata middleware .Metadata , err error )
func github.com/aws/aws-sdk-go-v2/service/internal/s3shared/config.ResolveUseARNRegion (ctx Context , configs []interface{}) (value bool , found bool , err error )
func github.com/aws/aws-sdk-go-v2/service/internal/s3shared/config.UseARNRegionProvider .GetS3UseARNRegion (ctx Context ) (value bool , found bool , err error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*BucketExistsWaiter ).Wait (ctx Context , params *s3 .HeadBucketInput , maxWaitDur time .Duration , optFns ...func(*s3 .BucketExistsWaiterOptions )) error
func github.com/aws/aws-sdk-go-v2/service/s3.(*BucketExistsWaiter ).WaitForOutput (ctx Context , params *s3 .HeadBucketInput , maxWaitDur time .Duration , optFns ...func(*s3 .BucketExistsWaiterOptions )) (*s3 .HeadBucketOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*BucketNotExistsWaiter ).Wait (ctx Context , params *s3 .HeadBucketInput , maxWaitDur time .Duration , optFns ...func(*s3 .BucketNotExistsWaiterOptions )) error
func github.com/aws/aws-sdk-go-v2/service/s3.(*BucketNotExistsWaiter ).WaitForOutput (ctx Context , params *s3 .HeadBucketInput , maxWaitDur time .Duration , optFns ...func(*s3 .BucketNotExistsWaiterOptions )) (*s3 .HeadBucketOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).AbortMultipartUpload (ctx Context , params *s3 .AbortMultipartUploadInput , optFns ...func(*s3 .Options )) (*s3 .AbortMultipartUploadOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).CompleteMultipartUpload (ctx Context , params *s3 .CompleteMultipartUploadInput , optFns ...func(*s3 .Options )) (*s3 .CompleteMultipartUploadOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).CopyObject (ctx Context , params *s3 .CopyObjectInput , optFns ...func(*s3 .Options )) (*s3 .CopyObjectOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).CreateBucket (ctx Context , params *s3 .CreateBucketInput , optFns ...func(*s3 .Options )) (*s3 .CreateBucketOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).CreateMultipartUpload (ctx Context , params *s3 .CreateMultipartUploadInput , optFns ...func(*s3 .Options )) (*s3 .CreateMultipartUploadOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).DeleteBucket (ctx Context , params *s3 .DeleteBucketInput , optFns ...func(*s3 .Options )) (*s3 .DeleteBucketOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).DeleteBucketAnalyticsConfiguration (ctx Context , params *s3 .DeleteBucketAnalyticsConfigurationInput , optFns ...func(*s3 .Options )) (*s3 .DeleteBucketAnalyticsConfigurationOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).DeleteBucketCors (ctx Context , params *s3 .DeleteBucketCorsInput , optFns ...func(*s3 .Options )) (*s3 .DeleteBucketCorsOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).DeleteBucketEncryption (ctx Context , params *s3 .DeleteBucketEncryptionInput , optFns ...func(*s3 .Options )) (*s3 .DeleteBucketEncryptionOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).DeleteBucketIntelligentTieringConfiguration (ctx Context , params *s3 .DeleteBucketIntelligentTieringConfigurationInput , optFns ...func(*s3 .Options )) (*s3 .DeleteBucketIntelligentTieringConfigurationOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).DeleteBucketInventoryConfiguration (ctx Context , params *s3 .DeleteBucketInventoryConfigurationInput , optFns ...func(*s3 .Options )) (*s3 .DeleteBucketInventoryConfigurationOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).DeleteBucketLifecycle (ctx Context , params *s3 .DeleteBucketLifecycleInput , optFns ...func(*s3 .Options )) (*s3 .DeleteBucketLifecycleOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).DeleteBucketMetricsConfiguration (ctx Context , params *s3 .DeleteBucketMetricsConfigurationInput , optFns ...func(*s3 .Options )) (*s3 .DeleteBucketMetricsConfigurationOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).DeleteBucketOwnershipControls (ctx Context , params *s3 .DeleteBucketOwnershipControlsInput , optFns ...func(*s3 .Options )) (*s3 .DeleteBucketOwnershipControlsOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).DeleteBucketPolicy (ctx Context , params *s3 .DeleteBucketPolicyInput , optFns ...func(*s3 .Options )) (*s3 .DeleteBucketPolicyOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).DeleteBucketReplication (ctx Context , params *s3 .DeleteBucketReplicationInput , optFns ...func(*s3 .Options )) (*s3 .DeleteBucketReplicationOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).DeleteBucketTagging (ctx Context , params *s3 .DeleteBucketTaggingInput , optFns ...func(*s3 .Options )) (*s3 .DeleteBucketTaggingOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).DeleteBucketWebsite (ctx Context , params *s3 .DeleteBucketWebsiteInput , optFns ...func(*s3 .Options )) (*s3 .DeleteBucketWebsiteOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).DeleteObject (ctx Context , params *s3 .DeleteObjectInput , optFns ...func(*s3 .Options )) (*s3 .DeleteObjectOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).DeleteObjects (ctx Context , params *s3 .DeleteObjectsInput , optFns ...func(*s3 .Options )) (*s3 .DeleteObjectsOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).DeleteObjectTagging (ctx Context , params *s3 .DeleteObjectTaggingInput , optFns ...func(*s3 .Options )) (*s3 .DeleteObjectTaggingOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).DeletePublicAccessBlock (ctx Context , params *s3 .DeletePublicAccessBlockInput , optFns ...func(*s3 .Options )) (*s3 .DeletePublicAccessBlockOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).GetBucketAccelerateConfiguration (ctx Context , params *s3 .GetBucketAccelerateConfigurationInput , optFns ...func(*s3 .Options )) (*s3 .GetBucketAccelerateConfigurationOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).GetBucketAcl (ctx Context , params *s3 .GetBucketAclInput , optFns ...func(*s3 .Options )) (*s3 .GetBucketAclOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).GetBucketAnalyticsConfiguration (ctx Context , params *s3 .GetBucketAnalyticsConfigurationInput , optFns ...func(*s3 .Options )) (*s3 .GetBucketAnalyticsConfigurationOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).GetBucketCors (ctx Context , params *s3 .GetBucketCorsInput , optFns ...func(*s3 .Options )) (*s3 .GetBucketCorsOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).GetBucketEncryption (ctx Context , params *s3 .GetBucketEncryptionInput , optFns ...func(*s3 .Options )) (*s3 .GetBucketEncryptionOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).GetBucketIntelligentTieringConfiguration (ctx Context , params *s3 .GetBucketIntelligentTieringConfigurationInput , optFns ...func(*s3 .Options )) (*s3 .GetBucketIntelligentTieringConfigurationOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).GetBucketInventoryConfiguration (ctx Context , params *s3 .GetBucketInventoryConfigurationInput , optFns ...func(*s3 .Options )) (*s3 .GetBucketInventoryConfigurationOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).GetBucketLifecycleConfiguration (ctx Context , params *s3 .GetBucketLifecycleConfigurationInput , optFns ...func(*s3 .Options )) (*s3 .GetBucketLifecycleConfigurationOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).GetBucketLocation (ctx Context , params *s3 .GetBucketLocationInput , optFns ...func(*s3 .Options )) (*s3 .GetBucketLocationOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).GetBucketLogging (ctx Context , params *s3 .GetBucketLoggingInput , optFns ...func(*s3 .Options )) (*s3 .GetBucketLoggingOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).GetBucketMetricsConfiguration (ctx Context , params *s3 .GetBucketMetricsConfigurationInput , optFns ...func(*s3 .Options )) (*s3 .GetBucketMetricsConfigurationOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).GetBucketNotificationConfiguration (ctx Context , params *s3 .GetBucketNotificationConfigurationInput , optFns ...func(*s3 .Options )) (*s3 .GetBucketNotificationConfigurationOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).GetBucketOwnershipControls (ctx Context , params *s3 .GetBucketOwnershipControlsInput , optFns ...func(*s3 .Options )) (*s3 .GetBucketOwnershipControlsOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).GetBucketPolicy (ctx Context , params *s3 .GetBucketPolicyInput , optFns ...func(*s3 .Options )) (*s3 .GetBucketPolicyOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).GetBucketPolicyStatus (ctx Context , params *s3 .GetBucketPolicyStatusInput , optFns ...func(*s3 .Options )) (*s3 .GetBucketPolicyStatusOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).GetBucketReplication (ctx Context , params *s3 .GetBucketReplicationInput , optFns ...func(*s3 .Options )) (*s3 .GetBucketReplicationOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).GetBucketRequestPayment (ctx Context , params *s3 .GetBucketRequestPaymentInput , optFns ...func(*s3 .Options )) (*s3 .GetBucketRequestPaymentOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).GetBucketTagging (ctx Context , params *s3 .GetBucketTaggingInput , optFns ...func(*s3 .Options )) (*s3 .GetBucketTaggingOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).GetBucketVersioning (ctx Context , params *s3 .GetBucketVersioningInput , optFns ...func(*s3 .Options )) (*s3 .GetBucketVersioningOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).GetBucketWebsite (ctx Context , params *s3 .GetBucketWebsiteInput , optFns ...func(*s3 .Options )) (*s3 .GetBucketWebsiteOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).GetObject (ctx Context , params *s3 .GetObjectInput , optFns ...func(*s3 .Options )) (*s3 .GetObjectOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).GetObjectAcl (ctx Context , params *s3 .GetObjectAclInput , optFns ...func(*s3 .Options )) (*s3 .GetObjectAclOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).GetObjectAttributes (ctx Context , params *s3 .GetObjectAttributesInput , optFns ...func(*s3 .Options )) (*s3 .GetObjectAttributesOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).GetObjectLegalHold (ctx Context , params *s3 .GetObjectLegalHoldInput , optFns ...func(*s3 .Options )) (*s3 .GetObjectLegalHoldOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).GetObjectLockConfiguration (ctx Context , params *s3 .GetObjectLockConfigurationInput , optFns ...func(*s3 .Options )) (*s3 .GetObjectLockConfigurationOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).GetObjectRetention (ctx Context , params *s3 .GetObjectRetentionInput , optFns ...func(*s3 .Options )) (*s3 .GetObjectRetentionOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).GetObjectTagging (ctx Context , params *s3 .GetObjectTaggingInput , optFns ...func(*s3 .Options )) (*s3 .GetObjectTaggingOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).GetObjectTorrent (ctx Context , params *s3 .GetObjectTorrentInput , optFns ...func(*s3 .Options )) (*s3 .GetObjectTorrentOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).GetPublicAccessBlock (ctx Context , params *s3 .GetPublicAccessBlockInput , optFns ...func(*s3 .Options )) (*s3 .GetPublicAccessBlockOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).HeadBucket (ctx Context , params *s3 .HeadBucketInput , optFns ...func(*s3 .Options )) (*s3 .HeadBucketOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).HeadObject (ctx Context , params *s3 .HeadObjectInput , optFns ...func(*s3 .Options )) (*s3 .HeadObjectOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).ListBucketAnalyticsConfigurations (ctx Context , params *s3 .ListBucketAnalyticsConfigurationsInput , optFns ...func(*s3 .Options )) (*s3 .ListBucketAnalyticsConfigurationsOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).ListBucketIntelligentTieringConfigurations (ctx Context , params *s3 .ListBucketIntelligentTieringConfigurationsInput , optFns ...func(*s3 .Options )) (*s3 .ListBucketIntelligentTieringConfigurationsOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).ListBucketInventoryConfigurations (ctx Context , params *s3 .ListBucketInventoryConfigurationsInput , optFns ...func(*s3 .Options )) (*s3 .ListBucketInventoryConfigurationsOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).ListBucketMetricsConfigurations (ctx Context , params *s3 .ListBucketMetricsConfigurationsInput , optFns ...func(*s3 .Options )) (*s3 .ListBucketMetricsConfigurationsOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).ListBuckets (ctx Context , params *s3 .ListBucketsInput , optFns ...func(*s3 .Options )) (*s3 .ListBucketsOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).ListMultipartUploads (ctx Context , params *s3 .ListMultipartUploadsInput , optFns ...func(*s3 .Options )) (*s3 .ListMultipartUploadsOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).ListObjects (ctx Context , params *s3 .ListObjectsInput , optFns ...func(*s3 .Options )) (*s3 .ListObjectsOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).ListObjectsV2 (ctx Context , params *s3 .ListObjectsV2Input , optFns ...func(*s3 .Options )) (*s3 .ListObjectsV2Output , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).ListObjectVersions (ctx Context , params *s3 .ListObjectVersionsInput , optFns ...func(*s3 .Options )) (*s3 .ListObjectVersionsOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).ListParts (ctx Context , params *s3 .ListPartsInput , optFns ...func(*s3 .Options )) (*s3 .ListPartsOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).PutBucketAccelerateConfiguration (ctx Context , params *s3 .PutBucketAccelerateConfigurationInput , optFns ...func(*s3 .Options )) (*s3 .PutBucketAccelerateConfigurationOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).PutBucketAcl (ctx Context , params *s3 .PutBucketAclInput , optFns ...func(*s3 .Options )) (*s3 .PutBucketAclOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).PutBucketAnalyticsConfiguration (ctx Context , params *s3 .PutBucketAnalyticsConfigurationInput , optFns ...func(*s3 .Options )) (*s3 .PutBucketAnalyticsConfigurationOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).PutBucketCors (ctx Context , params *s3 .PutBucketCorsInput , optFns ...func(*s3 .Options )) (*s3 .PutBucketCorsOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).PutBucketEncryption (ctx Context , params *s3 .PutBucketEncryptionInput , optFns ...func(*s3 .Options )) (*s3 .PutBucketEncryptionOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).PutBucketIntelligentTieringConfiguration (ctx Context , params *s3 .PutBucketIntelligentTieringConfigurationInput , optFns ...func(*s3 .Options )) (*s3 .PutBucketIntelligentTieringConfigurationOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).PutBucketInventoryConfiguration (ctx Context , params *s3 .PutBucketInventoryConfigurationInput , optFns ...func(*s3 .Options )) (*s3 .PutBucketInventoryConfigurationOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).PutBucketLifecycleConfiguration (ctx Context , params *s3 .PutBucketLifecycleConfigurationInput , optFns ...func(*s3 .Options )) (*s3 .PutBucketLifecycleConfigurationOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).PutBucketLogging (ctx Context , params *s3 .PutBucketLoggingInput , optFns ...func(*s3 .Options )) (*s3 .PutBucketLoggingOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).PutBucketMetricsConfiguration (ctx Context , params *s3 .PutBucketMetricsConfigurationInput , optFns ...func(*s3 .Options )) (*s3 .PutBucketMetricsConfigurationOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).PutBucketNotificationConfiguration (ctx Context , params *s3 .PutBucketNotificationConfigurationInput , optFns ...func(*s3 .Options )) (*s3 .PutBucketNotificationConfigurationOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).PutBucketOwnershipControls (ctx Context , params *s3 .PutBucketOwnershipControlsInput , optFns ...func(*s3 .Options )) (*s3 .PutBucketOwnershipControlsOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).PutBucketPolicy (ctx Context , params *s3 .PutBucketPolicyInput , optFns ...func(*s3 .Options )) (*s3 .PutBucketPolicyOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).PutBucketReplication (ctx Context , params *s3 .PutBucketReplicationInput , optFns ...func(*s3 .Options )) (*s3 .PutBucketReplicationOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).PutBucketRequestPayment (ctx Context , params *s3 .PutBucketRequestPaymentInput , optFns ...func(*s3 .Options )) (*s3 .PutBucketRequestPaymentOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).PutBucketTagging (ctx Context , params *s3 .PutBucketTaggingInput , optFns ...func(*s3 .Options )) (*s3 .PutBucketTaggingOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).PutBucketVersioning (ctx Context , params *s3 .PutBucketVersioningInput , optFns ...func(*s3 .Options )) (*s3 .PutBucketVersioningOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).PutBucketWebsite (ctx Context , params *s3 .PutBucketWebsiteInput , optFns ...func(*s3 .Options )) (*s3 .PutBucketWebsiteOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).PutObject (ctx Context , params *s3 .PutObjectInput , optFns ...func(*s3 .Options )) (*s3 .PutObjectOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).PutObjectAcl (ctx Context , params *s3 .PutObjectAclInput , optFns ...func(*s3 .Options )) (*s3 .PutObjectAclOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).PutObjectLegalHold (ctx Context , params *s3 .PutObjectLegalHoldInput , optFns ...func(*s3 .Options )) (*s3 .PutObjectLegalHoldOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).PutObjectLockConfiguration (ctx Context , params *s3 .PutObjectLockConfigurationInput , optFns ...func(*s3 .Options )) (*s3 .PutObjectLockConfigurationOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).PutObjectRetention (ctx Context , params *s3 .PutObjectRetentionInput , optFns ...func(*s3 .Options )) (*s3 .PutObjectRetentionOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).PutObjectTagging (ctx Context , params *s3 .PutObjectTaggingInput , optFns ...func(*s3 .Options )) (*s3 .PutObjectTaggingOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).PutPublicAccessBlock (ctx Context , params *s3 .PutPublicAccessBlockInput , optFns ...func(*s3 .Options )) (*s3 .PutPublicAccessBlockOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).RestoreObject (ctx Context , params *s3 .RestoreObjectInput , optFns ...func(*s3 .Options )) (*s3 .RestoreObjectOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).SelectObjectContent (ctx Context , params *s3 .SelectObjectContentInput , optFns ...func(*s3 .Options )) (*s3 .SelectObjectContentOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).UploadPart (ctx Context , params *s3 .UploadPartInput , optFns ...func(*s3 .Options )) (*s3 .UploadPartOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).UploadPartCopy (ctx Context , params *s3 .UploadPartCopyInput , optFns ...func(*s3 .Options )) (*s3 .UploadPartCopyOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).WriteGetObjectResponse (ctx Context , params *s3 .WriteGetObjectResponseInput , optFns ...func(*s3 .Options )) (*s3 .WriteGetObjectResponseOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.HeadBucketAPIClient .HeadBucket (Context , *s3 .HeadBucketInput , ...func(*s3 .Options )) (*s3 .HeadBucketOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.HeadObjectAPIClient .HeadObject (Context , *s3 .HeadObjectInput , ...func(*s3 .Options )) (*s3 .HeadObjectOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.HTTPPresignerV4 .PresignHTTP (ctx Context , credentials aws .Credentials , r *http .Request , payloadHash string , service string , region string , signingTime time .Time , optFns ...func(*v4 .SignerOptions )) (url string , signedHeader http .Header , err error )
func github.com/aws/aws-sdk-go-v2/service/s3.HTTPSignerV4 .SignHTTP (ctx Context , credentials aws .Credentials , r *http .Request , payloadHash string , service string , region string , signingTime time .Time , optFns ...func(*v4 .SignerOptions )) error
func github.com/aws/aws-sdk-go-v2/service/s3.ListObjectsV2APIClient .ListObjectsV2 (Context , *s3 .ListObjectsV2Input , ...func(*s3 .Options )) (*s3 .ListObjectsV2Output , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*ListObjectsV2Paginator ).NextPage (ctx Context , optFns ...func(*s3 .Options )) (*s3 .ListObjectsV2Output , error )
func github.com/aws/aws-sdk-go-v2/service/s3.ListPartsAPIClient .ListParts (Context , *s3 .ListPartsInput , ...func(*s3 .Options )) (*s3 .ListPartsOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*ListPartsPaginator ).NextPage (ctx Context , optFns ...func(*s3 .Options )) (*s3 .ListPartsOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*ObjectExistsWaiter ).Wait (ctx Context , params *s3 .HeadObjectInput , maxWaitDur time .Duration , optFns ...func(*s3 .ObjectExistsWaiterOptions )) error
func github.com/aws/aws-sdk-go-v2/service/s3.(*ObjectExistsWaiter ).WaitForOutput (ctx Context , params *s3 .HeadObjectInput , maxWaitDur time .Duration , optFns ...func(*s3 .ObjectExistsWaiterOptions )) (*s3 .HeadObjectOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*ObjectNotExistsWaiter ).Wait (ctx Context , params *s3 .HeadObjectInput , maxWaitDur time .Duration , optFns ...func(*s3 .ObjectNotExistsWaiterOptions )) error
func github.com/aws/aws-sdk-go-v2/service/s3.(*ObjectNotExistsWaiter ).WaitForOutput (ctx Context , params *s3 .HeadObjectInput , maxWaitDur time .Duration , optFns ...func(*s3 .ObjectNotExistsWaiterOptions )) (*s3 .HeadObjectOutput , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*PresignClient ).PresignDeleteBucket (ctx Context , params *s3 .DeleteBucketInput , optFns ...func(*s3 .PresignOptions )) (*v4 .PresignedHTTPRequest , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*PresignClient ).PresignDeleteObject (ctx Context , params *s3 .DeleteObjectInput , optFns ...func(*s3 .PresignOptions )) (*v4 .PresignedHTTPRequest , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*PresignClient ).PresignGetObject (ctx Context , params *s3 .GetObjectInput , optFns ...func(*s3 .PresignOptions )) (*v4 .PresignedHTTPRequest , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*PresignClient ).PresignHeadBucket (ctx Context , params *s3 .HeadBucketInput , optFns ...func(*s3 .PresignOptions )) (*v4 .PresignedHTTPRequest , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*PresignClient ).PresignHeadObject (ctx Context , params *s3 .HeadObjectInput , optFns ...func(*s3 .PresignOptions )) (*v4 .PresignedHTTPRequest , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*PresignClient ).PresignPutObject (ctx Context , params *s3 .PutObjectInput , optFns ...func(*s3 .PresignOptions )) (*v4 .PresignedHTTPRequest , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*PresignClient ).PresignUploadPart (ctx Context , params *s3 .UploadPartInput , optFns ...func(*s3 .PresignOptions )) (*v4 .PresignedHTTPRequest , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*ResolveEndpoint ).HandleSerialize (ctx Context , in middleware .SerializeInput , next middleware .SerializeHandler ) (out middleware .SerializeOutput , metadata middleware .Metadata , err error )
func github.com/aws/aws-sdk-go-v2/service/s3/internal/customizations.GetSignerVersion (ctx Context ) (v string )
func github.com/aws/aws-sdk-go-v2/service/s3/internal/customizations.SetSignerVersion (ctx Context , version string ) Context
func github.com/aws/aws-sdk-go-v2/service/s3/internal/customizations.(*AddExpiresOnPresignedURL ).HandleBuild (ctx Context , in middleware .BuildInput , next middleware .BuildHandler ) (out middleware .BuildOutput , metadata middleware .Metadata , err error )
func github.com/aws/aws-sdk-go-v2/service/s3/internal/customizations.(*PresignHTTPRequestMiddleware ).HandleFinalize (ctx Context , in middleware .FinalizeInput , next middleware .FinalizeHandler ) (out middleware .FinalizeOutput , metadata middleware .Metadata , err error )
func github.com/aws/aws-sdk-go-v2/service/s3/internal/customizations.(*SignHTTPRequestMiddleware ).HandleFinalize (ctx Context , in middleware .FinalizeInput , next middleware .FinalizeHandler ) (out middleware .FinalizeOutput , metadata middleware .Metadata , err error )
func github.com/aws/smithy-go/auth/bearer.(*AuthenticationMiddleware ).HandleFinalize (ctx Context , in middleware .FinalizeInput , next middleware .FinalizeHandler ) (out middleware .FinalizeOutput , metadata middleware .Metadata , err error )
func github.com/aws/smithy-go/auth/bearer.Signer .SignWithBearerToken (Context , bearer .Token , bearer .Message ) (bearer .Message , error )
func github.com/aws/smithy-go/auth/bearer.SignHTTPSMessage .SignWithBearerToken (ctx Context , token bearer .Token , message bearer .Message ) (bearer .Message , error )
func github.com/aws/smithy-go/auth/bearer.StaticTokenProvider .RetrieveBearerToken (Context ) (bearer .Token , error )
func github.com/aws/smithy-go/auth/bearer.(*TokenCache ).RetrieveBearerToken (ctx Context ) (bearer .Token , error )
func github.com/aws/smithy-go/auth/bearer.TokenProvider .RetrieveBearerToken (Context ) (bearer .Token , error )
func github.com/aws/smithy-go/auth/bearer.TokenProviderFunc .RetrieveBearerToken (ctx Context ) (bearer .Token , error )
func github.com/aws/smithy-go/context.GetPreserveExpiredValues (ctx Context ) bool
func github.com/aws/smithy-go/context.WithPreserveExpiredValues (ctx Context , enable bool ) Context
func github.com/aws/smithy-go/context.WithSuppressCancel (ctx Context ) Context
func github.com/aws/smithy-go/logging.WithContext (ctx Context , logger logging .Logger ) logging .Logger
func github.com/aws/smithy-go/logging.ContextLogger .WithContext (Context ) logging .Logger
func github.com/aws/smithy-go/middleware.ClearStackValues (ctx Context ) Context
func github.com/aws/smithy-go/middleware.GetLogger (ctx Context ) logging .Logger
func github.com/aws/smithy-go/middleware.GetStackValue (ctx Context , key interface{}) interface{}
func github.com/aws/smithy-go/middleware.SetLogger (ctx Context , logger logging .Logger ) Context
func github.com/aws/smithy-go/middleware.WithStackValue (ctx Context , key, value interface{}) Context
func github.com/aws/smithy-go/middleware.BuildHandler .HandleBuild (ctx Context , in middleware .BuildInput ) (out middleware .BuildOutput , metadata middleware .Metadata , err error )
func github.com/aws/smithy-go/middleware.BuildHandlerFunc .HandleBuild (ctx Context , in middleware .BuildInput ) (middleware .BuildOutput , middleware .Metadata , error )
func github.com/aws/smithy-go/middleware.BuildMiddleware .HandleBuild (ctx Context , in middleware .BuildInput , next middleware .BuildHandler ) (out middleware .BuildOutput , metadata middleware .Metadata , err error )
func github.com/aws/smithy-go/middleware.(*BuildStep ).HandleMiddleware (ctx Context , in interface{}, next middleware .Handler ) (out interface{}, metadata middleware .Metadata , err error )
func github.com/aws/smithy-go/middleware.DeserializeHandler .HandleDeserialize (ctx Context , in middleware .DeserializeInput ) (out middleware .DeserializeOutput , metadata middleware .Metadata , err error )
func github.com/aws/smithy-go/middleware.DeserializeHandlerFunc .HandleDeserialize (ctx Context , in middleware .DeserializeInput ) (middleware .DeserializeOutput , middleware .Metadata , error )
func github.com/aws/smithy-go/middleware.DeserializeMiddleware .HandleDeserialize (ctx Context , in middleware .DeserializeInput , next middleware .DeserializeHandler ) (out middleware .DeserializeOutput , metadata middleware .Metadata , err error )
func github.com/aws/smithy-go/middleware.(*DeserializeStep ).HandleMiddleware (ctx Context , in interface{}, next middleware .Handler ) (out interface{}, metadata middleware .Metadata , err error )
func github.com/aws/smithy-go/middleware.FinalizeHandler .HandleFinalize (ctx Context , in middleware .FinalizeInput ) (out middleware .FinalizeOutput , metadata middleware .Metadata , err error )
func github.com/aws/smithy-go/middleware.FinalizeHandlerFunc .HandleFinalize (ctx Context , in middleware .FinalizeInput ) (middleware .FinalizeOutput , middleware .Metadata , error )
func github.com/aws/smithy-go/middleware.FinalizeMiddleware .HandleFinalize (ctx Context , in middleware .FinalizeInput , next middleware .FinalizeHandler ) (out middleware .FinalizeOutput , metadata middleware .Metadata , err error )
func github.com/aws/smithy-go/middleware.(*FinalizeStep ).HandleMiddleware (ctx Context , in interface{}, next middleware .Handler ) (out interface{}, metadata middleware .Metadata , err error )
func github.com/aws/smithy-go/middleware.Handler .Handle (ctx Context , input interface{}) (output interface{}, metadata middleware .Metadata , err error )
func github.com/aws/smithy-go/middleware.HandlerFunc .Handle (ctx Context , input interface{}) (output interface{}, metadata middleware .Metadata , err error )
func github.com/aws/smithy-go/middleware.InitializeHandler .HandleInitialize (ctx Context , in middleware .InitializeInput ) (out middleware .InitializeOutput , metadata middleware .Metadata , err error )
func github.com/aws/smithy-go/middleware.InitializeHandlerFunc .HandleInitialize (ctx Context , in middleware .InitializeInput ) (middleware .InitializeOutput , middleware .Metadata , error )
func github.com/aws/smithy-go/middleware.InitializeMiddleware .HandleInitialize (ctx Context , in middleware .InitializeInput , next middleware .InitializeHandler ) (out middleware .InitializeOutput , metadata middleware .Metadata , err error )
func github.com/aws/smithy-go/middleware.(*InitializeStep ).HandleMiddleware (ctx Context , in interface{}, next middleware .Handler ) (out interface{}, metadata middleware .Metadata , err error )
func github.com/aws/smithy-go/middleware.Middleware .HandleMiddleware (ctx Context , input interface{}, next middleware .Handler ) (output interface{}, metadata middleware .Metadata , err error )
func github.com/aws/smithy-go/middleware.SerializeHandler .HandleSerialize (ctx Context , in middleware .SerializeInput ) (out middleware .SerializeOutput , metadata middleware .Metadata , err error )
func github.com/aws/smithy-go/middleware.SerializeHandlerFunc .HandleSerialize (ctx Context , in middleware .SerializeInput ) (middleware .SerializeOutput , middleware .Metadata , error )
func github.com/aws/smithy-go/middleware.SerializeMiddleware .HandleSerialize (ctx Context , in middleware .SerializeInput , next middleware .SerializeHandler ) (out middleware .SerializeOutput , metadata middleware .Metadata , err error )
func github.com/aws/smithy-go/middleware.(*SerializeStep ).HandleMiddleware (ctx Context , in interface{}, next middleware .Handler ) (out interface{}, metadata middleware .Metadata , err error )
func github.com/aws/smithy-go/middleware.(*Stack ).HandleMiddleware (ctx Context , input interface{}, next middleware .Handler ) (output interface{}, metadata middleware .Metadata , err error )
func github.com/aws/smithy-go/time.SleepWithContext (ctx Context , dur time .Duration ) error
func github.com/aws/smithy-go/transport/http.DisableEndpointHostPrefix (ctx Context , value bool ) Context
func github.com/aws/smithy-go/transport/http.GetHostnameImmutable (ctx Context ) (v bool )
func github.com/aws/smithy-go/transport/http.GetIsContentTypeDefaultValue (ctx Context ) bool
func github.com/aws/smithy-go/transport/http.IsEndpointHostPrefixDisabled (ctx Context ) (v bool )
func github.com/aws/smithy-go/transport/http.SetHostnameImmutable (ctx Context , value bool ) Context
func github.com/aws/smithy-go/transport/http.SetIsContentTypeDefaultValue (ctx Context , isDefault bool ) Context
func github.com/aws/smithy-go/transport/http.ClientHandler .Handle (ctx Context , input interface{}) (out interface{}, metadata middleware .Metadata , err error )
func github.com/aws/smithy-go/transport/http.(*ComputeContentLength ).HandleBuild (ctx Context , in middleware .BuildInput , next middleware .BuildHandler ) (out middleware .BuildOutput , metadata middleware .Metadata , err error )
func github.com/aws/smithy-go/transport/http.(*Request ).Build (ctx Context ) *http .Request
func github.com/aws/smithy-go/transport/http.(*RequestResponseLogger ).HandleDeserialize (ctx Context , in middleware .DeserializeInput , next middleware .DeserializeHandler ) (out middleware .DeserializeOutput , metadata middleware .Metadata , err error )
func github.com/aws/smithy-go/transport/http.(*RequireMinimumProtocol ).HandleDeserialize (ctx Context , in middleware .DeserializeInput , next middleware .DeserializeHandler ) (out middleware .DeserializeOutput , metadata middleware .Metadata , err error )
func github.com/aws/smithy-go/waiter.(*Logger ).HandleInitialize (ctx Context , in middleware .InitializeInput , next middleware .InitializeHandler ) (out middleware .InitializeOutput , metadata middleware .Metadata , err error )
func github.com/go-pg/pg/v10.ModelContext (c Context , model ...interface{}) *pg .Query
func github.com/go-pg/pg/v10.AfterDeleteHook .AfterDelete (Context ) error
func github.com/go-pg/pg/v10.AfterInsertHook .AfterInsert (Context ) error
func github.com/go-pg/pg/v10.AfterScanHook .AfterScan (Context ) error
func github.com/go-pg/pg/v10.AfterSelectHook .AfterSelect (Context ) error
func github.com/go-pg/pg/v10.AfterUpdateHook .AfterUpdate (Context ) error
func github.com/go-pg/pg/v10.BeforeDeleteHook .BeforeDelete (Context ) (Context , error )
func github.com/go-pg/pg/v10.BeforeInsertHook .BeforeInsert (Context ) (Context , error )
func github.com/go-pg/pg/v10.BeforeScanHook .BeforeScan (Context ) error
func github.com/go-pg/pg/v10.BeforeUpdateHook .BeforeUpdate (Context ) (Context , error )
func github.com/go-pg/pg/v10.(*Conn ).WithContext (ctx Context ) *pg .Conn
func github.com/go-pg/pg/v10.(*DB ).Listen (ctx Context , channels ...string ) *pg .Listener
func github.com/go-pg/pg/v10.(*DB ).WithContext (ctx Context ) *pg .DB
func github.com/go-pg/pg/v10.DBI .ExecContext (c Context , query interface{}, params ...interface{}) (pg .Result , error )
func github.com/go-pg/pg/v10.DBI .ExecOneContext (c Context , query interface{}, params ...interface{}) (pg .Result , error )
func github.com/go-pg/pg/v10.DBI .ModelContext (c Context , model ...interface{}) *pg .Query
func github.com/go-pg/pg/v10.DBI .QueryContext (c Context , model, query interface{}, params ...interface{}) (pg .Result , error )
func github.com/go-pg/pg/v10.DBI .QueryOneContext (c Context , model, query interface{}, params ...interface{}) (pg .Result , error )
func github.com/go-pg/pg/v10.DBI .RunInTransaction (ctx Context , fn func(*pg .Tx ) error ) error
func github.com/go-pg/pg/v10.(*Listener ).Listen (ctx Context , channels ...string ) error
func github.com/go-pg/pg/v10.(*Listener ).Receive (ctx Context ) (channel string , payload string , err error )
func github.com/go-pg/pg/v10.(*Listener ).ReceiveTimeout (ctx Context , timeout time .Duration ) (channel, payload string , err error )
func github.com/go-pg/pg/v10.(*Listener ).Unlisten (ctx Context , channels ...string ) error
func github.com/go-pg/pg/v10.QueryHook .AfterQuery (Context , *pg .QueryEvent ) error
func github.com/go-pg/pg/v10.QueryHook .BeforeQuery (Context , *pg .QueryEvent ) (Context , error )
func github.com/go-pg/pg/v10.(*Stmt ).ExecContext (c Context , params ...interface{}) (pg .Result , error )
func github.com/go-pg/pg/v10.(*Stmt ).ExecOneContext (c Context , params ...interface{}) (pg .Result , error )
func github.com/go-pg/pg/v10.(*Stmt ).QueryContext (c Context , model interface{}, params ...interface{}) (pg .Result , error )
func github.com/go-pg/pg/v10.(*Stmt ).QueryOneContext (c Context , model interface{}, params ...interface{}) (pg .Result , error )
func github.com/go-pg/pg/v10.(*Tx ).CloseContext (ctx Context ) error
func github.com/go-pg/pg/v10.(*Tx ).CommitContext (ctx Context ) error
func github.com/go-pg/pg/v10.(*Tx ).ExecContext (c Context , query interface{}, params ...interface{}) (pg .Result , error )
func github.com/go-pg/pg/v10.(*Tx ).ExecOneContext (c Context , query interface{}, params ...interface{}) (pg .Result , error )
func github.com/go-pg/pg/v10.(*Tx ).ModelContext (c Context , model ...interface{}) *pg .Query
func github.com/go-pg/pg/v10.(*Tx ).QueryContext (c Context , model interface{}, query interface{}, params ...interface{}) (pg .Result , error )
func github.com/go-pg/pg/v10.(*Tx ).QueryOneContext (c Context , model interface{}, query interface{}, params ...interface{}) (pg .Result , error )
func github.com/go-pg/pg/v10.(*Tx ).RollbackContext (ctx Context ) error
func github.com/go-pg/pg/v10.(*Tx ).RunInTransaction (ctx Context , fn func(*pg .Tx ) error ) error
func github.com/go-pg/pg/v10/internal.Sleep (ctx Context , dur time .Duration ) error
func github.com/go-pg/pg/v10/internal.UndoContext (ctx Context ) internal .UndoneContext
func github.com/go-pg/pg/v10/internal.Logging .Printf (ctx Context , format string , v ...interface{})
func github.com/go-pg/pg/v10/internal/pool.(*Conn ).WithReader (ctx Context , timeout time .Duration , fn func(rd *pool .ReaderContext ) error ) error
func github.com/go-pg/pg/v10/internal/pool.(*Conn ).WithWriter (ctx Context , timeout time .Duration , fn func(wb *pool .WriteBuffer ) error ) error
func github.com/go-pg/pg/v10/internal/pool.(*Conn ).WriteBuffer (ctx Context , timeout time .Duration , wb *pool .WriteBuffer ) error
func github.com/go-pg/pg/v10/internal/pool.(*ConnPool ).Get (ctx Context ) (*pool .Conn , error )
func github.com/go-pg/pg/v10/internal/pool.(*ConnPool ).NewConn (c Context ) (*pool .Conn , error )
func github.com/go-pg/pg/v10/internal/pool.(*ConnPool ).Put (ctx Context , cn *pool .Conn )
func github.com/go-pg/pg/v10/internal/pool.(*ConnPool ).Remove (ctx Context , cn *pool .Conn , reason error )
func github.com/go-pg/pg/v10/internal/pool.Pooler .Get (Context ) (*pool .Conn , error )
func github.com/go-pg/pg/v10/internal/pool.Pooler .NewConn (Context ) (*pool .Conn , error )
func github.com/go-pg/pg/v10/internal/pool.Pooler .Put (Context , *pool .Conn )
func github.com/go-pg/pg/v10/internal/pool.Pooler .Remove (Context , *pool .Conn , error )
func github.com/go-pg/pg/v10/internal/pool.(*SingleConnPool ).Get (ctx Context ) (*pool .Conn , error )
func github.com/go-pg/pg/v10/internal/pool.(*SingleConnPool ).NewConn (ctx Context ) (*pool .Conn , error )
func github.com/go-pg/pg/v10/internal/pool.(*SingleConnPool ).Put (ctx Context , cn *pool .Conn )
func github.com/go-pg/pg/v10/internal/pool.(*SingleConnPool ).Remove (ctx Context , cn *pool .Conn , reason error )
func github.com/go-pg/pg/v10/internal/pool.(*StickyConnPool ).Get (ctx Context ) (*pool .Conn , error )
func github.com/go-pg/pg/v10/internal/pool.(*StickyConnPool ).NewConn (ctx Context ) (*pool .Conn , error )
func github.com/go-pg/pg/v10/internal/pool.(*StickyConnPool ).Put (ctx Context , cn *pool .Conn )
func github.com/go-pg/pg/v10/internal/pool.(*StickyConnPool ).Remove (ctx Context , cn *pool .Conn , reason error )
func github.com/go-pg/pg/v10/internal/pool.(*StickyConnPool ).Reset (ctx Context ) error
func github.com/go-pg/pg/v10/orm.NewQueryContext (ctx Context , db orm .DB , model ...interface{}) *orm .Query
func github.com/go-pg/pg/v10/orm.AfterDeleteHook .AfterDelete (Context ) error
func github.com/go-pg/pg/v10/orm.AfterInsertHook .AfterInsert (Context ) error
func github.com/go-pg/pg/v10/orm.AfterScanHook .AfterScan (Context ) error
func github.com/go-pg/pg/v10/orm.AfterSelectHook .AfterSelect (Context ) error
func github.com/go-pg/pg/v10/orm.AfterUpdateHook .AfterUpdate (Context ) error
func github.com/go-pg/pg/v10/orm.BeforeDeleteHook .BeforeDelete (Context ) (Context , error )
func github.com/go-pg/pg/v10/orm.BeforeInsertHook .BeforeInsert (Context ) (Context , error )
func github.com/go-pg/pg/v10/orm.BeforeScanHook .BeforeScan (Context ) error
func github.com/go-pg/pg/v10/orm.BeforeUpdateHook .BeforeUpdate (Context ) (Context , error )
func github.com/go-pg/pg/v10/orm.DB .ExecContext (c Context , query interface{}, params ...interface{}) (orm .Result , error )
func github.com/go-pg/pg/v10/orm.DB .ExecOneContext (c Context , query interface{}, params ...interface{}) (orm .Result , error )
func github.com/go-pg/pg/v10/orm.DB .ModelContext (c Context , model ...interface{}) *orm .Query
func github.com/go-pg/pg/v10/orm.DB .QueryContext (c Context , model, query interface{}, params ...interface{}) (orm .Result , error )
func github.com/go-pg/pg/v10/orm.DB .QueryOneContext (c Context , model, query interface{}, params ...interface{}) (orm .Result , error )
func github.com/go-pg/pg/v10/orm.Model .AfterDelete (Context ) error
func github.com/go-pg/pg/v10/orm.Model .AfterInsert (Context ) error
func github.com/go-pg/pg/v10/orm.Model .AfterScan (Context ) error
func github.com/go-pg/pg/v10/orm.Model .AfterSelect (Context ) error
func github.com/go-pg/pg/v10/orm.Model .AfterUpdate (Context ) error
func github.com/go-pg/pg/v10/orm.Model .BeforeDelete (Context ) (Context , error )
func github.com/go-pg/pg/v10/orm.Model .BeforeInsert (Context ) (Context , error )
func github.com/go-pg/pg/v10/orm.Model .BeforeUpdate (Context ) (Context , error )
func github.com/go-pg/pg/v10/orm.(*Query ).Context (c Context ) *orm .Query
func github.com/go-pg/pg/v10/orm.TableModel .AfterDelete (Context ) error
func github.com/go-pg/pg/v10/orm.TableModel .AfterInsert (Context ) error
func github.com/go-pg/pg/v10/orm.TableModel .AfterScan (Context ) error
func github.com/go-pg/pg/v10/orm.TableModel .AfterSelect (Context ) error
func github.com/go-pg/pg/v10/orm.TableModel .AfterUpdate (Context ) error
func github.com/go-pg/pg/v10/orm.TableModel .BeforeDelete (Context ) (Context , error )
func github.com/go-pg/pg/v10/orm.TableModel .BeforeInsert (Context ) (Context , error )
func github.com/go-pg/pg/v10/orm.TableModel .BeforeUpdate (Context ) (Context , error )
func github.com/golang/mock/gomock.WithContext (ctx Context , t gomock .TestReporter ) (*gomock .Controller , Context )
func go.pact.im/x/flaky.(*DebounceExecutor ).Execute (ctx Context , f flaky .Op ) error
func go.pact.im/x/flaky.Executor .Execute (ctx Context , f flaky .Op ) error
func go.pact.im/x/flaky.(*RetryExecutor ).Execute (ctx Context , f flaky .Op ) error
func go.pact.im/x/flaky.(*ScheduleExecutor ).Execute (ctx Context , f flaky .Op ) error
func go.pact.im/x/flaky.(*WatchdogExecutor ).Execute (ctx Context , f flaky .Op ) error
func go.pact.im/x/names.Namer .Name (ctx Context ) (string , error )
func go.pact.im/x/names/dockernames.(*Namer ).Name (ctx Context ) (string , error )
func go.pact.im/x/names/monikernames.(*Namer ).Name (ctx Context ) (string , error )
func go.pact.im/x/process.NewProcess (ctx Context , proc process .Runnable ) *process .Process
func go.pact.im/x/process.(*Process ).Start (ctx Context ) error
func go.pact.im/x/process.(*Process ).Stop (ctx Context ) error
func go.pact.im/x/process.Runnable .Run (ctx Context , callback process .Callback ) error
func go.pact.im/x/process.RunnableFunc .Run (ctx Context , callback process .Callback ) error
func go.pact.im/x/supervisor.Iterator .Get (ctx Context ) (K, V, error )
func go.pact.im/x/supervisor.(*Supervisor )[K, P].Get (ctx Context , pk K) (P, error )
func go.pact.im/x/supervisor.(*Supervisor )[K, P].Run (ctx Context , callback process .Callback ) error
func go.pact.im/x/supervisor.(*Supervisor )[K, P].Start (ctx Context , pk K) (P, error )
func go.pact.im/x/supervisor.(*Supervisor )[K, P].Stop (ctx Context , pk K) error
func go.pact.im/x/supervisor.Table .Get (ctx Context , key K) (V, error )
func go.pact.im/x/supervisor.Table .Iter (ctx Context ) (supervisor .Iterator [K, V], error )
func go.pact.im/x/syncx.Lock .Acquire (ctx Context ) error
func go.pact.im/x/task.Executor .Execute (ctx Context , cond task .CancelCondition , tasks ...task .Task ) error
func go.pact.im/x/task.Task .Run (ctx Context ) 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/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/sync/errgroup.WithContext (ctx Context ) (*errgroup .Group , Context )
func golang.org/x/sys/execabs.CommandContext (ctx Context , name string , arg ...string ) *exec .Cmd
func golang.org/x/tools/go/internal/packagesdriver.GetSizesGolist (ctx Context , inv gocommand .Invocation , gocmdRunner *gocommand .Runner ) (types .Sizes , error )
func golang.org/x/tools/internal/event.Detach (ctx Context ) Context
func golang.org/x/tools/internal/event.Error (ctx Context , message string , err error , labels ...label .Label )
func golang.org/x/tools/internal/event.Label (ctx Context , labels ...label .Label ) Context
func golang.org/x/tools/internal/event.Log (ctx Context , message string , labels ...label .Label )
func golang.org/x/tools/internal/event.Metric (ctx Context , labels ...label .Label )
func golang.org/x/tools/internal/event.Start (ctx Context , name string , labels ...label .Label ) (Context , func())
func golang.org/x/tools/internal/event/core.Export (ctx Context , ev core .Event ) Context
func golang.org/x/tools/internal/event/core.ExportPair (ctx Context , begin, end core .Event ) (Context , func())
func golang.org/x/tools/internal/event/core.Log1 (ctx Context , message string , t1 label .Label )
func golang.org/x/tools/internal/event/core.Log2 (ctx Context , message string , t1 label .Label , t2 label .Label )
func golang.org/x/tools/internal/event/core.Metric1 (ctx Context , t1 label .Label ) Context
func golang.org/x/tools/internal/event/core.Metric2 (ctx Context , t1, t2 label .Label ) Context
func golang.org/x/tools/internal/event/core.Start1 (ctx Context , name string , t1 label .Label ) (Context , func())
func golang.org/x/tools/internal/event/core.Start2 (ctx Context , name string , t1, t2 label .Label ) (Context , func())
func golang.org/x/tools/internal/gocommand.GoVersion (ctx Context , inv gocommand .Invocation , r *gocommand .Runner ) (int , error )
func golang.org/x/tools/internal/gocommand.GoVersionOutput (ctx Context , inv gocommand .Invocation , r *gocommand .Runner ) (string , error )
func golang.org/x/tools/internal/gocommand.VendorEnabled (ctx Context , inv gocommand .Invocation , r *gocommand .Runner ) (bool , *gocommand .ModuleJSON , error )
func golang.org/x/tools/internal/gocommand.(*Runner ).Run (ctx Context , inv gocommand .Invocation ) (*bytes .Buffer , error )
func golang.org/x/tools/internal/gocommand.(*Runner ).RunPiped (ctx Context , inv gocommand .Invocation , stdout, stderr io .Writer ) error
func golang.org/x/tools/internal/gocommand.(*Runner ).RunRaw (ctx Context , inv gocommand .Invocation ) (*bytes .Buffer , *bytes .Buffer , error , error )
func google.golang.org/grpc.DialContext (ctx Context , target string , opts ...grpc .DialOption ) (conn *grpc .ClientConn , err error )
func google.golang.org/grpc.Invoke (ctx Context , method string , args, reply interface{}, cc *grpc .ClientConn , opts ...grpc .CallOption ) error
func google.golang.org/grpc.Method (ctx Context ) (string , bool )
func google.golang.org/grpc.NewClientStream (ctx Context , desc *grpc .StreamDesc , cc *grpc .ClientConn , method string , opts ...grpc .CallOption ) (grpc .ClientStream , error )
func google.golang.org/grpc.NewContextWithServerTransportStream (ctx Context , stream grpc .ServerTransportStream ) Context
func google.golang.org/grpc.SendHeader (ctx Context , md metadata .MD ) error
func google.golang.org/grpc.ServerTransportStreamFromContext (ctx Context ) grpc .ServerTransportStream
func google.golang.org/grpc.SetHeader (ctx Context , md metadata .MD ) error
func google.golang.org/grpc.SetTrailer (ctx Context , md metadata .MD ) error
func google.golang.org/grpc.(*ClientConn ).Invoke (ctx Context , method string , args, reply interface{}, opts ...grpc .CallOption ) error
func google.golang.org/grpc.(*ClientConn ).NewStream (ctx Context , desc *grpc .StreamDesc , method string , opts ...grpc .CallOption ) (grpc .ClientStream , error )
func google.golang.org/grpc.(*ClientConn ).WaitForStateChange (ctx Context , sourceState connectivity .State ) bool
func google.golang.org/grpc.ClientConnInterface .Invoke (ctx Context , method string , args interface{}, reply interface{}, opts ...grpc .CallOption ) error
func google.golang.org/grpc.ClientConnInterface .NewStream (ctx Context , desc *grpc .StreamDesc , method string , opts ...grpc .CallOption ) (grpc .ClientStream , error )
func google.golang.org/grpc/credentials.ClientHandshakeInfoFromContext (ctx Context ) credentials .ClientHandshakeInfo
func google.golang.org/grpc/credentials.RequestInfoFromContext (ctx Context ) (ri credentials .RequestInfo , ok bool )
func google.golang.org/grpc/credentials.PerRPCCredentials .GetRequestMetadata (ctx Context , uri ...string ) (map[string ]string , error )
func google.golang.org/grpc/credentials.TransportCredentials .ClientHandshake (Context , string , net .Conn ) (net .Conn , credentials .AuthInfo , error )
func google.golang.org/grpc/internal/credentials.ClientHandshakeInfoFromContext (ctx Context ) interface{}
func google.golang.org/grpc/internal/credentials.NewClientHandshakeInfoContext (ctx Context , chi interface{}) Context
func google.golang.org/grpc/internal/credentials.NewRequestInfoContext (ctx Context , ri interface{}) Context
func google.golang.org/grpc/internal/credentials.RequestInfoFromContext (ctx Context ) interface{}
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/transport.GetConnection (ctx Context ) net .Conn
func google.golang.org/grpc/internal/transport.NewClientTransport (connectCtx, ctx Context , addr resolver .Address , opts transport .ConnectOptions , onClose func(transport .GoAwayReason )) (transport .ClientTransport , error )
func google.golang.org/grpc/internal/transport.ClientTransport .NewStream (ctx Context , callHdr *transport .CallHdr ) (*transport .Stream , error )
func google.golang.org/grpc/metadata.AppendToOutgoingContext (ctx Context , kv ...string ) Context
func google.golang.org/grpc/metadata.FromIncomingContext (ctx Context ) (metadata .MD , bool )
func google.golang.org/grpc/metadata.FromOutgoingContext (ctx Context ) (metadata .MD , bool )
func google.golang.org/grpc/metadata.FromOutgoingContextRaw (ctx Context ) (metadata .MD , [][]string , bool )
func google.golang.org/grpc/metadata.NewIncomingContext (ctx Context , md metadata .MD ) Context
func google.golang.org/grpc/metadata.NewOutgoingContext (ctx Context , md metadata .MD ) Context
func google.golang.org/grpc/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.OutgoingTags (ctx Context ) []byte
func google.golang.org/grpc/stats.OutgoingTrace (ctx Context ) []byte
func google.golang.org/grpc/stats.SetIncomingTags (ctx Context , b []byte ) Context
func google.golang.org/grpc/stats.SetIncomingTrace (ctx Context , b []byte ) Context
func google.golang.org/grpc/stats.SetTags (ctx Context , b []byte ) Context
func google.golang.org/grpc/stats.SetTrace (ctx Context , b []byte ) Context
func google.golang.org/grpc/stats.Tags (ctx Context ) []byte
func google.golang.org/grpc/stats.Trace (ctx Context ) []byte
func google.golang.org/grpc/stats.Handler .HandleConn (Context , stats .ConnStats )
func google.golang.org/grpc/stats.Handler .HandleRPC (Context , stats .RPCStats )
func google.golang.org/grpc/stats.Handler .TagConn (Context , *stats .ConnTagInfo ) Context
func google.golang.org/grpc/stats.Handler .TagRPC (Context , *stats .RPCTagInfo ) Context
func internal/execabs.CommandContext (ctx Context , name string , arg ...string ) *exec .Cmd
func net.(*Dialer ).DialContext (ctx Context , network, address string ) (net .Conn , error )
func net.(*ListenConfig ).Listen (ctx Context , network, address string ) (net .Listener , error )
func net.(*ListenConfig ).ListenPacket (ctx Context , network, address string ) (net .PacketConn , error )
func net.(*Resolver ).LookupAddr (ctx Context , addr string ) ([]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/httptrace.ContextClientTrace (ctx Context ) *httptrace .ClientTrace
func net/http/httptrace.WithClientTrace (ctx Context , trace *httptrace .ClientTrace ) Context
func os/exec.CommandContext (ctx Context , name string , arg ...string ) *exec .Cmd
func runtime/pprof.Do (ctx Context , labels pprof .LabelSet , f func(Context ))
func runtime/pprof.ForLabels (ctx Context , f func(key, value string ) bool )
func runtime/pprof.Label (ctx Context , key string ) (string , bool )
func runtime/pprof.SetGoroutineLabels (ctx Context )
func runtime/pprof.WithLabels (ctx Context , labels pprof .LabelSet ) Context
func runtime/trace.Log (ctx Context , category, message string )
func runtime/trace.Logf (ctx Context , category, format string , args ...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())
/* 200+ unexporteds ... */ /* 200+ unexporteds: */
func contextName (c Context ) string
func newCancelCtx (parent Context ) cancelCtx
func parentCancelCtx (parent Context ) (*cancelCtx , bool )
func propagateCancel (parent Context , child canceler )
func removeChild (parent Context , child canceler )
func value (c Context , key any ) any
func crypto/tls.certificateRequestInfoFromMsg (ctx Context , vers uint16 , certReq *tls .certificateRequestMsg ) *tls .CertificateRequestInfo
func crypto/tls.clientHelloInfo (ctx Context , c *tls .Conn , clientHello *tls .clientHelloMsg ) *tls .ClientHelloInfo
func crypto/tls.dial (ctx Context , netDialer *net .Dialer , network, addr string , config *tls .Config ) (*tls .Conn , error )
func crypto/tls.(*Conn ).clientHandshake (ctx Context ) (err error )
func crypto/tls.(*Conn ).handshakeContext (ctx Context ) (ret error )
func crypto/tls.(*Conn ).readClientHello (ctx Context ) (*tls .clientHelloMsg , error )
func crypto/tls.(*Conn ).serverHandshake (ctx Context ) error
func database/sql.ctxDriverBegin (ctx Context , opts *sql .TxOptions , ci driver .Conn ) (driver .Tx , error )
func database/sql.ctxDriverExec (ctx Context , execerCtx driver .ExecerContext , execer driver .Execer , query string , nvdargs []driver .NamedValue ) (driver .Result , error )
func database/sql.ctxDriverPrepare (ctx Context , ci driver .Conn , query string ) (driver .Stmt , error )
func database/sql.ctxDriverQuery (ctx Context , queryerCtx driver .QueryerContext , queryer driver .Queryer , query string , nvdargs []driver .NamedValue ) (driver .Rows , error )
func database/sql.ctxDriverStmtExec (ctx Context , si driver .Stmt , nvdargs []driver .NamedValue ) (driver .Result , error )
func database/sql.ctxDriverStmtQuery (ctx Context , si driver .Stmt , nvdargs []driver .NamedValue ) (driver .Rows , error )
func database/sql.resultFromStatement (ctx Context , ci driver .Conn , ds *sql .driverStmt , args ...any ) (sql .Result , error )
func database/sql.rowsiFromStatement (ctx Context , ci driver .Conn , ds *sql .driverStmt , args ...any ) (driver .Rows , error )
func database/sql.(*Conn ).grabConn (Context ) (*sql .driverConn , sql .releaseConn , error )
func database/sql.(*DB ).begin (ctx Context , opts *sql .TxOptions , strategy sql .connReuseStrategy ) (tx *sql .Tx , err error )
func database/sql.(*DB ).beginDC (ctx Context , dc *sql .driverConn , release func(error ), opts *sql .TxOptions ) (tx *sql .Tx , err error )
func database/sql.(*DB ).conn (ctx Context , strategy sql .connReuseStrategy ) (*sql .driverConn , error )
func database/sql.(*DB ).connectionOpener (ctx Context )
func database/sql.(*DB ).exec (ctx Context , query string , args []any , strategy sql .connReuseStrategy ) (sql .Result , error )
func database/sql.(*DB ).execDC (ctx Context , dc *sql .driverConn , release func(error ), query string , args []any ) (res sql .Result , err error )
func database/sql.(*DB ).openNewConnection (ctx Context )
func database/sql.(*DB ).pingDC (ctx Context , dc *sql .driverConn , release func(error )) error
func database/sql.(*DB ).prepare (ctx Context , query string , strategy sql .connReuseStrategy ) (*sql .Stmt , error )
func database/sql.(*DB ).prepareDC (ctx Context , dc *sql .driverConn , release func(error ), cg sql .stmtConnGrabber , query string ) (*sql .Stmt , error )
func database/sql.(*DB ).query (ctx Context , query string , args []any , strategy sql .connReuseStrategy ) (*sql .Rows , error )
func database/sql.(*DB ).queryDC (ctx, txctx Context , dc *sql .driverConn , releaseConn func(error ), query string , args []any ) (*sql .Rows , error )
func database/sql.(*Rows ).awaitDone (ctx, txctx Context )
func database/sql.(*Rows ).initContextClose (ctx, txctx Context )
func database/sql.(*Stmt ).connStmt (ctx Context , strategy sql .connReuseStrategy ) (dc *sql .driverConn , releaseConn func(error ), ds *sql .driverStmt , err error )
func database/sql.(*Stmt ).prepareOnConnLocked (ctx Context , dc *sql .driverConn ) (*sql .driverStmt , error )
func database/sql.(*Tx ).grabConn (ctx Context ) (*sql .driverConn , sql .releaseConn , error )
func github.com/aws/aws-sdk-go-v2/aws.defaultHandleFailToRefresh (ctx Context , _ aws .Credentials , err error ) (aws .Credentials , error )
func github.com/aws/aws-sdk-go-v2/aws.(*CredentialsCache ).singleRetrieve (ctx Context ) (interface{}, error )
func github.com/aws/aws-sdk-go-v2/aws/middleware.setOperationName (ctx Context , value string ) Context
func github.com/aws/aws-sdk-go-v2/aws/middleware.setRegion (ctx Context , value string ) Context
func github.com/aws/aws-sdk-go-v2/aws/protocol/eventstream/eventstreamapi.setInputStreamWriter (ctx Context , writeCloser io .WriteCloser ) Context
func github.com/aws/aws-sdk-go-v2/aws/retry.getRetryMetadata (ctx Context ) (metadata retry .retryMetadata , ok bool )
func github.com/aws/aws-sdk-go-v2/aws/retry.setRetryMetadata (ctx Context , metadata retry .retryMetadata ) Context
func github.com/aws/aws-sdk-go-v2/aws/retry.(*Attempt ).handleAttempt (ctx Context , in smithymiddle .FinalizeInput , releaseRetryToken func(error ) error , next smithymiddle .FinalizeHandler ) (out smithymiddle .FinalizeOutput , attemptResult retry .AttemptResult , _ func(error ) error , err error )
func github.com/aws/aws-sdk-go-v2/aws/signer/v4.logSigningInfo (ctx Context , options v4 .SignerOptions , request *v4 .signedRequest , isPresign bool )
func github.com/aws/aws-sdk-go-v2/internal/sdk.noOpSleepWithContext (Context , time .Duration ) error
func github.com/aws/aws-sdk-go-v2/internal/sdk.sleepWithContext (ctx Context , dur time .Duration ) error
func github.com/aws/aws-sdk-go-v2/internal/v4a.logHTTPSigningInfo (ctx Context , options v4a .SignerOptions , r v4a .signedRequest )
func github.com/aws/aws-sdk-go-v2/internal/v4a.(*SymmetricCredentialAdaptor ).retrieveFromSymmetricProvider (ctx Context ) (aws .Credentials , error )
func github.com/aws/aws-sdk-go-v2/service/internal/checksum.getContextInputAlgorithm (ctx Context ) (v string )
func github.com/aws/aws-sdk-go-v2/service/internal/checksum.getContextOutputValidationMode (ctx Context ) (v string )
func github.com/aws/aws-sdk-go-v2/service/internal/checksum.getInputAlgorithm (ctx Context ) (checksum .Algorithm , bool , error )
func github.com/aws/aws-sdk-go-v2/service/internal/checksum.setContextInputAlgorithm (ctx Context , value string ) Context
func github.com/aws/aws-sdk-go-v2/service/internal/checksum.setContextOutputValidationMode (ctx Context , value string ) Context
func github.com/aws/aws-sdk-go-v2/service/internal/checksum.setMD5Checksum (ctx Context , req *smithyhttp .Request ) (string , error )
func github.com/aws/aws-sdk-go-v2/service/internal/s3shared.setARNResourceOnContext (ctx Context , value arn .ARN ) Context
func github.com/aws/aws-sdk-go-v2/service/s3.bucketExistsStateRetryable (ctx Context , input *s3 .HeadBucketInput , output *s3 .HeadBucketOutput , err error ) (bool , error )
func github.com/aws/aws-sdk-go-v2/service/s3.bucketNotExistsStateRetryable (ctx Context , input *s3 .HeadBucketInput , output *s3 .HeadBucketOutput , err error ) (bool , error )
func github.com/aws/aws-sdk-go-v2/service/s3.objectExistsStateRetryable (ctx Context , input *s3 .HeadObjectInput , output *s3 .HeadObjectOutput , err error ) (bool , error )
func github.com/aws/aws-sdk-go-v2/service/s3.objectNotExistsStateRetryable (ctx Context , input *s3 .HeadObjectInput , output *s3 .HeadObjectOutput , err error ) (bool , error )
func github.com/aws/aws-sdk-go-v2/service/s3.(*Client ).invokeOperation (ctx Context , opID string , params interface{}, optFns []func(*s3 .Options ), stackFns ...func(*middleware .Stack , s3 .Options ) error ) (result interface{}, metadata middleware .Metadata , err error )
func github.com/aws/aws-sdk-go-v2/service/s3/internal/customizations.buildAccessPointHostPrefix (ctx Context , req *http .Request , tv arn .AccessPointARN ) (Context , error )
func github.com/aws/aws-sdk-go-v2/service/s3/internal/customizations.buildAccessPointRequest (ctx Context , options customizations .accesspointOptions ) (Context , error )
func github.com/aws/aws-sdk-go-v2/service/s3/internal/customizations.buildMultiRegionAccessPointsRequest (ctx Context , options customizations .accesspointOptions ) (Context , error )
func github.com/aws/aws-sdk-go-v2/service/s3/internal/customizations.buildOutpostAccessPointRequest (ctx Context , options customizations .outpostAccessPointOptions ) (Context , error )
func github.com/aws/aws-sdk-go-v2/service/s3/internal/customizations.buildS3ObjectLambdaAccessPointRequest (ctx Context , options customizations .accesspointOptions ) (Context , error )
func github.com/aws/aws-sdk-go-v2/service/s3/internal/customizations.getRemoveBucketFromPath (ctx Context ) (string , bool )
func github.com/aws/aws-sdk-go-v2/service/s3/internal/customizations.setBucketToRemoveOnContext (ctx Context , bucket string ) Context
func github.com/aws/smithy-go/auth/bearer.(*TokenCache ).refreshBearerToken (ctx Context ) (bearer .Token , error )
func github.com/aws/smithy-go/auth/bearer.(*TokenCache ).singleRetrieve (ctx Context ) (interface{}, error )
func github.com/aws/smithy-go/auth/bearer.(*TokenCache ).tryAsyncRefresh (ctx Context )
func github.com/go-pg/pg/v10.newConn (ctx Context , baseDB *pg .baseDB ) *pg .Conn
func github.com/go-pg/pg/v10.newDB (ctx Context , baseDB *pg .baseDB ) *pg .DB
func github.com/go-pg/pg/v10.readDataRow (ctx Context , rd *pool .ReaderContext , columns []types .ColumnInfo , scanner orm .ColumnScanner ) error
func github.com/go-pg/pg/v10.readExtQueryData (ctx Context , rd *pool .ReaderContext , mod interface{}, columns []types .ColumnInfo ) (*pg .result , error )
func github.com/go-pg/pg/v10.readSimpleQueryData (ctx Context , rd *pool .ReaderContext , mod interface{}) (*pg .result , error )
func github.com/go-pg/pg/v10.(*Listener ).conn (ctx Context ) (*pool .Conn , error )
func github.com/go-pg/pg/v10.(*Listener ).connWithLock (ctx Context ) (*pool .Conn , error )
func github.com/go-pg/pg/v10.(*Listener ).listen (ctx Context , cn *pool .Conn , channels ...string ) error
func github.com/go-pg/pg/v10.(*Listener ).reconnect (ctx Context , reason error )
func github.com/go-pg/pg/v10.(*Listener ).releaseConn (ctx Context , cn *pool .Conn , err error , allowTimeout bool )
func github.com/go-pg/pg/v10.(*Listener ).unlisten (ctx Context , cn *pool .Conn , channels ...string ) error
func github.com/go-pg/pg/v10.(*Stmt ).exec (ctx Context , params ...interface{}) (pg .Result , error )
func github.com/go-pg/pg/v10.(*Stmt ).execOne (c Context , params ...interface{}) (pg .Result , error )
func github.com/go-pg/pg/v10.(*Stmt ).extQuery (c Context , cn *pool .Conn , name string , params ...interface{}) (pg .Result , error )
func github.com/go-pg/pg/v10.(*Stmt ).extQueryData (c Context , cn *pool .Conn , name string , model interface{}, columns []types .ColumnInfo , params ...interface{}) (pg .Result , error )
func github.com/go-pg/pg/v10.(*Stmt ).prepare (ctx Context , q string ) error
func github.com/go-pg/pg/v10.(*Stmt ).query (ctx Context , model interface{}, params ...interface{}) (pg .Result , error )
func github.com/go-pg/pg/v10.(*Stmt ).queryOne (c Context , model interface{}, params ...interface{}) (pg .Result , error )
func github.com/go-pg/pg/v10.(*Stmt ).withConn (c Context , fn func(Context , *pool .Conn ) error ) error
func github.com/go-pg/pg/v10.(*Tx ).begin (ctx Context ) error
func github.com/go-pg/pg/v10.(*Tx ).exec (ctx Context , query interface{}, params ...interface{}) (pg .Result , error )
func github.com/go-pg/pg/v10.(*Tx ).execOne (c Context , query interface{}, params ...interface{}) (pg .Result , error )
func github.com/go-pg/pg/v10.(*Tx ).query (ctx Context , model interface{}, query interface{}, params ...interface{}) (pg .Result , error )
func github.com/go-pg/pg/v10.(*Tx ).queryOne (c Context , model interface{}, query interface{}, params ...interface{}) (pg .Result , error )
func github.com/go-pg/pg/v10.(*Tx ).withConn (c Context , fn func(Context , *pool .Conn ) error ) error
func github.com/go-pg/pg/v10/internal/pool.(*Conn ).deadline (ctx Context , timeout time .Duration ) time .Time
func github.com/go-pg/pg/v10/internal/pool.(*Conn ).writeBuffer (ctx Context , timeout time .Duration , wb *pool .WriteBuffer ) error
func github.com/go-pg/pg/v10/internal/pool.(*ConnPool ).dialConn (c Context , pooled bool ) (*pool .Conn , error )
func github.com/go-pg/pg/v10/internal/pool.(*ConnPool ).newConn (c Context , pooled bool ) (*pool .Conn , error )
func github.com/go-pg/pg/v10/internal/pool.(*ConnPool ).waitTurn (c Context ) error
func github.com/go-pg/pg/v10/internal/pool.(*StickyConnPool ).freeConn (ctx Context , cn *pool .Conn )
func github.com/go-pg/pg/v10/orm.callAfterDeleteHook (ctx Context , v reflect .Value ) error
func github.com/go-pg/pg/v10/orm.callAfterDeleteHookSlice (ctx Context , slice reflect .Value , ptr bool ) error
func github.com/go-pg/pg/v10/orm.callAfterInsertHook (ctx Context , v reflect .Value ) error
func github.com/go-pg/pg/v10/orm.callAfterInsertHookSlice (ctx Context , slice reflect .Value , ptr bool ) error
func github.com/go-pg/pg/v10/orm.callAfterScanHook (ctx Context , v reflect .Value ) error
func github.com/go-pg/pg/v10/orm.callAfterSelectHook (ctx Context , v reflect .Value ) error
func github.com/go-pg/pg/v10/orm.callAfterSelectHookSlice (ctx Context , slice reflect .Value , ptr bool ) error
func github.com/go-pg/pg/v10/orm.callAfterUpdateHook (ctx Context , v reflect .Value ) error
func github.com/go-pg/pg/v10/orm.callAfterUpdateHookSlice (ctx Context , slice reflect .Value , ptr bool ) error
func github.com/go-pg/pg/v10/orm.callBeforeDeleteHook (ctx Context , v reflect .Value ) (Context , error )
func github.com/go-pg/pg/v10/orm.callBeforeDeleteHookSlice (ctx Context , slice reflect .Value , ptr bool ) (Context , error )
func github.com/go-pg/pg/v10/orm.callBeforeInsertHook (ctx Context , v reflect .Value ) (Context , error )
func github.com/go-pg/pg/v10/orm.callBeforeInsertHookSlice (ctx Context , slice reflect .Value , ptr bool ) (Context , error )
func github.com/go-pg/pg/v10/orm.callBeforeScanHook (ctx Context , v reflect .Value ) error
func github.com/go-pg/pg/v10/orm.callBeforeUpdateHook (ctx Context , v reflect .Value ) (Context , error )
func github.com/go-pg/pg/v10/orm.callBeforeUpdateHookSlice (ctx Context , slice reflect .Value , ptr bool ) (Context , error )
func github.com/go-pg/pg/v10/orm.callHookSlice (ctx Context , slice reflect .Value , ptr bool , hook func(Context , reflect .Value ) (Context , error )) (Context , error )
func github.com/go-pg/pg/v10/orm.callHookSlice2 (ctx Context , slice reflect .Value , ptr bool , hook func(Context , reflect .Value ) error ) error
func github.com/go-pg/pg/v10/orm.(*Query ).query (ctx Context , model orm .Model , query interface{}) (orm .Result , error )
func github.com/go-pg/pg/v10/orm.(*Query ).returningQuery (c Context , model orm .Model , query interface{}) (orm .Result , error )
func go.pact.im/x/flaky.withinDeadline (ctx Context , d time .Duration ) bool
func go.pact.im/x/supervisor.(*Supervisor )[K, P].restart (ctx Context , wait time .Duration ) error
func go.pact.im/x/supervisor.(*Supervisor )[K, P].restartInitial (ctx Context )
func go.pact.im/x/supervisor.(*Supervisor )[K, P].restartLoop (ctx Context )
func go.pact.im/x/supervisor.(*Supervisor )[K, P].restartProcessInBackground (ctx Context , pk K, r P) <-chan struct{}
func go.pact.im/x/supervisor.(*Supervisor )[K, P].spawnRestartLoop (ctx Context ) func()
func go.pact.im/x/supervisor.(*Supervisor )[K, P].startProcess (ctx Context , pk K, r P) (*supervisor .managedProcess [P], error )
func go.pact.im/x/supervisor.(*Supervisor )[K, P].startProcessForKey (ctx Context , pk K) (*supervisor .managedProcess [P], error )
func go.pact.im/x/supervisor.(*Supervisor )[K, P].startProcessUnlocked (ctx Context , pk K, r P) (*supervisor .managedProcess [P], error )
func go.pact.im/x/supervisor.(*Supervisor )[K, P].stopAll (ctx Context )
func go.pact.im/x/supervisor.(*Supervisor )[K, P].stopProcess (ctx Context , pk K) error
func golang.org/x/net/http2.(*Transport ).dialClientConn (ctx Context , addr string , singleUse bool ) (*http2 .ClientConn , error )
func golang.org/x/net/http2.(*Transport ).dialTLS (ctx Context , network, addr string , tlsCfg *tls .Config ) (net .Conn , error )
func golang.org/x/net/http2.(*Transport ).dialTLSWithContext (ctx Context , network, addr string , cfg *tls .Config ) (*tls .Conn , error )
func golang.org/x/tools/internal/event/core.deliver (ctx Context , exporter core .Exporter , ev core .Event ) Context
func golang.org/x/tools/internal/gocommand.getMainModuleAnd114 (ctx Context , inv gocommand .Invocation , r *gocommand .Runner ) (*gocommand .ModuleJSON , bool , error )
func golang.org/x/tools/internal/gocommand.runCmdContext (ctx Context , cmd *exec .Cmd ) error
func golang.org/x/tools/internal/gocommand.(*Invocation ).run (ctx Context , stdout, stderr io .Writer ) error
func golang.org/x/tools/internal/gocommand.(*Invocation ).runWithFriendlyError (ctx Context , stdout, stderr io .Writer ) (friendlyError error , rawError error )
func golang.org/x/tools/internal/gocommand.(*Runner ).runConcurrent (ctx Context , inv gocommand .Invocation ) (*bytes .Buffer , *bytes .Buffer , error , error )
func golang.org/x/tools/internal/gocommand.(*Runner ).runPiped (ctx Context , inv gocommand .Invocation , stdout, stderr io .Writer ) (error , error )
func google.golang.org/grpc.invoke (ctx Context , method string , req, reply interface{}, cc *grpc .ClientConn , opts ...grpc .CallOption ) error
func google.golang.org/grpc.newClientStream (ctx Context , desc *grpc .StreamDesc , cc *grpc .ClientConn , method string , opts ...grpc .CallOption ) (_ grpc .ClientStream , err error )
func google.golang.org/grpc.newClientStreamWithParams (ctx Context , desc *grpc .StreamDesc , cc *grpc .ClientConn , method string , mc serviceconfig .MethodConfig , onCommit, doneFunc func(), opts ...grpc .CallOption ) (_ iresolver .ClientStream , err error )
func google.golang.org/grpc.newContextWithRPCInfo (ctx Context , failfast bool , codec grpc .baseCodec , cp grpc .Compressor , comp encoding .Compressor ) Context
func google.golang.org/grpc.newNonRetryClientStream (ctx Context , desc *grpc .StreamDesc , method string , t transport .ClientTransport , ac *grpc .addrConn , opts ...grpc .CallOption ) (_ grpc .ClientStream , err error )
func google.golang.org/grpc.rpcInfoFromContext (ctx Context ) (s *grpc .rpcInfo , ok bool )
func google.golang.org/grpc.(*ClientConn ).getTransport (ctx Context , failfast bool , method string ) (transport .ClientTransport , balancer .PickResult , error )
func google.golang.org/grpc.(*ClientConn ).waitForResolvedAddrs (ctx Context ) error
func google.golang.org/grpc/internal/transport.dial (ctx Context , fn func(Context , string ) (net .Conn , error ), addr resolver .Address , useProxy bool , grpcUA string ) (net .Conn , error )
func google.golang.org/grpc/internal/transport.doHTTPConnectHandshake (ctx Context , conn net .Conn , backendAddr string , proxyURL *url .URL , grpcUA string ) (_ net .Conn , err error )
func google.golang.org/grpc/internal/transport.newHTTP2Client (connectCtx, ctx Context , addr resolver .Address , opts transport .ConnectOptions , onClose func(transport .GoAwayReason )) (_ *transport .http2Client , err error )
func google.golang.org/grpc/internal/transport.proxyDial (ctx Context , addr string , grpcUA string ) (conn net .Conn , err error )
func google.golang.org/grpc/internal/transport.sendHTTPRequest (ctx Context , req *http .Request , conn net .Conn ) error
func google.golang.org/grpc/internal/transport.setConnection (ctx Context , conn net .Conn ) Context
func net.cgoLookupCNAME (ctx Context , name string ) (cname string , err error , completed bool )
func net.cgoLookupHost (ctx Context , name string ) (hosts []string , err error , completed bool )
func net.cgoLookupIP (ctx Context , network, name string ) (addrs []net .IPAddr , err error , completed bool )
func net.cgoLookupPort (ctx Context , network, service string ) (port int , err error , completed bool )
func net.cgoLookupPTR (ctx Context , addr string ) (names []string , err error , completed bool )
func net.internetSocket (ctx Context , net string , laddr, raddr net .sockaddr , sotype, proto int , mode string , ctrlFn func(string , string , syscall .RawConn ) error ) (fd *net .netFD , err error )
func net.lookupProtocol (_ Context , name string ) (int , error )
func net.parseNetwork (ctx Context , network string , needsProto bool ) (afnet string , proto int , err error )
func net.socket (ctx Context , net string , family, sotype, proto int , ipv6only bool , laddr, raddr net .sockaddr , ctrlFn func(string , string , syscall .RawConn ) error ) (fd *net .netFD , err error )
func net.unixSocket (ctx Context , net string , laddr, raddr net .sockaddr , mode string , ctrlFn func(string , string , syscall .RawConn ) error ) (*net .netFD , error )
func net.withUnexpiredValuesPreserved (lookupCtx Context ) Context
func net.(*Dialer ).deadline (ctx Context , now time .Time ) (earliest time .Time )
func net.(*Resolver ).dial (ctx Context , network, server string ) (net .Conn , error )
func net.(*Resolver ).exchange (ctx Context , server string , q dnsmessage .Question , timeout time .Duration , useTCP bool ) (dnsmessage .Parser , dnsmessage .Header , error )
func net.(*Resolver ).goLookupCNAME (ctx Context , host string ) (string , error )
func net.(*Resolver ).goLookupHost (ctx Context , name string ) (addrs []string , err error )
func net.(*Resolver ).goLookupHostOrder (ctx Context , name string , order net .hostLookupOrder ) (addrs []string , err error )
func net.(*Resolver ).goLookupIP (ctx Context , network, host string ) (addrs []net .IPAddr , err error )
func net.(*Resolver ).goLookupIPCNAMEOrder (ctx Context , network, name string , order net .hostLookupOrder ) (addrs []net .IPAddr , cname dnsmessage .Name , err error )
func net.(*Resolver ).goLookupPTR (ctx Context , addr string ) ([]string , error )
func net.(*Resolver ).internetAddrList (ctx Context , net, addr string ) (net .addrList , error )
func net.(*Resolver ).lookup (ctx Context , name string , qtype dnsmessage .Type ) (dnsmessage .Parser , string , error )
func net.(*Resolver ).lookupAddr (ctx Context , addr string ) ([]string , error )
func net.(*Resolver ).lookupCNAME (ctx Context , name string ) (string , error )
func net.(*Resolver ).lookupHost (ctx Context , host string ) (addrs []string , err error )
func net.(*Resolver ).lookupIP (ctx Context , network, host string ) (addrs []net .IPAddr , err error )
func net.(*Resolver ).lookupIPAddr (ctx Context , network, host string ) ([]net .IPAddr , error )
func net.(*Resolver ).lookupMX (ctx Context , name string ) ([]*net .MX , error )
func net.(*Resolver ).lookupNS (ctx Context , name string ) ([]*net .NS , error )
func net.(*Resolver ).lookupPort (ctx Context , network, service string ) (int , 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.(*Resolver ).resolveAddrList (ctx Context , op, network, addr string , hint net .Addr ) (net .addrList , error )
func net.(*Resolver ).tryOneName (ctx Context , cfg *net .dnsConfig , name string , qtype dnsmessage .Type ) (dnsmessage .Parser , string , error )
func net/http.timeBeforeContextDeadline (t time .Time , ctx Context ) bool
func net/http.(*Transport ).customDialTLS (ctx Context , network, addr string ) (conn net .Conn , err error )
func net/http.(*Transport ).dial (ctx Context , network, addr string ) (net .Conn , error )
func net/http.(*Transport ).dialConn (ctx Context , cm http .connectMethod ) (pconn *http .persistConn , err error )
func runtime/pprof.labelValue (ctx Context ) pprof .labelMap
func runtime/trace.fromContext (ctx Context ) *trace .Task
/* 7 unexporteds ... */ /* 7 unexporteds: */ type cancelCtx (struct)
A cancelCtx can be canceled. When canceled, it also cancels any children
that implement canceler.
Fields (total 5, in which 1 are exported )
Context Context
/* 4 unexporteds ... */ /* 4 unexporteds: */
children map[canceler ]struct{}
// set to nil by the first cancel call
done atomic .Value
// of chan struct{}, created lazily, closed by first cancel call
err error
// set to non-nil by the first cancel call
mu sync .Mutex
// protects following fields
Methods (total 6, in which 5 are exported )
( cancelCtx) Deadline () (deadline time .Time , ok bool )
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.
(*cancelCtx) Done () <-chan struct{}
(*cancelCtx) Err () error
(*cancelCtx) String () string
(*cancelCtx) Value (key any ) any
/* one unexported ... */ /* one unexported: */
(*cancelCtx) cancel (removeFromParent bool , err error )
cancel closes c.done, cancels each of c's children, and, if
removeFromParent is true, removes c from its parent's children.
Implements (at least 7, in which 3 are exported )
*cancelCtx : Context
*cancelCtx : expvar.Var
*cancelCtx : fmt.Stringer
/* 4+ unexporteds ... */ /* 4+ unexporteds: */
*cancelCtx : canceler
*cancelCtx : stringer
*cancelCtx : github.com/aws/smithy-go/middleware.stringer
*cancelCtx : runtime.stringer
As Outputs Of (at least 2, neither is exported )
/* 2+ unexporteds ... */ /* 2+ unexporteds: */
func newCancelCtx (parent Context ) cancelCtx
func parentCancelCtx (parent Context ) (*cancelCtx , bool )
type valueCtx (struct)
A valueCtx carries a key-value pair. It implements Value for that key and
delegates all other calls to the embedded Context.
Fields (total 3, in which 1 are exported )
Context Context
/* 2 unexporteds ... */ /* 2 unexporteds: */
key any
val any
Methods (total 5, all are exported )
( valueCtx) Deadline () (deadline time .Time , ok bool )
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.
( valueCtx) Done () <-chan struct{}
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.
( valueCtx) Err () error
If Done is not yet closed, Err returns nil.
If Done is closed, Err returns a non-nil error explaining why:
Canceled if the context was canceled
or DeadlineExceeded if the context's deadline passed.
After Err returns a non-nil error, successive calls to Err return the same error.
(*valueCtx) String () string
(*valueCtx) Value (key any ) any
Implements (at least 6, in which 3 are exported )
*valueCtx : Context
*valueCtx : expvar.Var
*valueCtx : fmt.Stringer
/* 3+ unexporteds ... */ /* 3+ unexporteds: */
*valueCtx : stringer
*valueCtx : github.com/aws/smithy-go/middleware.stringer
*valueCtx : runtime.stringer