type context.Context
617 uses
context (current package)
context.go#L71: type Context interface {
context.go#L215: func Background() Context {
context.go#L223: func TODO() Context {
context.go#L240: func WithCancel(parent Context) (ctx Context, cancel CancelFunc) {
context.go#L268: func WithCancelCause(parent Context) (ctx Context, cancel CancelCauseFunc) {
context.go#L273: func withCancel(parent Context) *cancelCtx {
context.go#L288: func Cause(c Context) error {
context.go#L325: func AfterFunc(ctx Context, f func()) (stop func() bool) {
context.go#L366: Context
context.go#L382: func parentCancelCtx(parent Context) (*cancelCtx, bool) {
context.go#L399: func removeChild(parent Context, child canceler) {
context.go#L432: Context
context.go#L475: func (c *cancelCtx) propagateCancel(parent Context, child canceler) {
context.go#L535: func contextName(c Context) string {
context.go#L585: func WithoutCancel(parent Context) Context {
context.go#L593: c Context
context.go#L625: func WithDeadline(parent Context, d time.Time) (Context, CancelFunc) {
context.go#L632: func WithDeadlineCause(parent Context, d time.Time, cause error) (Context, CancelFunc) {
context.go#L703: func WithTimeout(parent Context, timeout time.Duration) (Context, CancelFunc) {
context.go#L710: func WithTimeoutCause(parent Context, timeout time.Duration, cause error) (Context, CancelFunc) {
context.go#L727: func WithValue(parent Context, key, val any) Context {
context.go#L743: Context
context.go#L775: func value(c Context, key any) any {
crypto/tls
common.go#L477: ctx context.Context
common.go#L483: func (c *ClientHelloInfo) Context() context.Context {
common.go#L505: ctx context.Context
common.go#L511: func (c *CertificateRequestInfo) Context() context.Context {
conn.go#L32: handshakeFn func(context.Context) error // (*Conn).clientHandshake or serverHandshake
conn.go#L1512: func (c *Conn) HandshakeContext(ctx context.Context) error {
conn.go#L1518: func (c *Conn) handshakeContext(ctx context.Context) (ret error) {
handshake_client.go#L34: ctx context.Context
handshake_client.go#L253: func (c *Conn) clientHandshake(ctx context.Context) (err error) {
handshake_client.go#L1213: func certificateRequestInfoFromMsg(ctx context.Context, vers uint16, certReq *certificateRequestMsg) *CertificateRequestInfo {
handshake_client_tls13.go#L25: ctx context.Context
handshake_server.go#L27: ctx context.Context
handshake_server.go#L42: func (c *Conn) serverHandshake(ctx context.Context) error {
handshake_server.go#L134: func (c *Conn) readClientHello(ctx context.Context) (*clientHelloMsg, *echServerContext, error) {
handshake_server.go#L1009: func clientHelloInfo(ctx context.Context, c *Conn, clientHello *clientHelloMsg) *ClientHelloInfo {
handshake_server_tls13.go#L47: ctx context.Context
quic.go#L203: func (q *QUICConn) Start(ctx context.Context) error {
tls.go#L134: func dial(ctx context.Context, netDialer *net.Dialer, network, addr string, config *Config) (*Conn, error) {
tls.go#L230: func (d *Dialer) DialContext(ctx context.Context, network, addr string) (net.Conn, error) {
github.com/robfig/cron/v3
cron.go#L323: func (c *Cron) Stop() context.Context {
go.pact.im/x/flaky
deadline.go#L9: func withinDeadline(ctx context.Context, d time.Duration) bool {
debounce.go#L93: func (d *DebounceExecutor) Execute(ctx context.Context, f Op) error {
flaky.go#L9: type Op func(ctx context.Context) error
flaky.go#L14: Execute(ctx context.Context, f Op) error
flaky.go#L18: type ExecutorFunc func(ctx context.Context, f Op) error
flaky.go#L21: func (f ExecutorFunc) Execute(ctx context.Context, op Op) error {
once.go#L16: func (*onceExecutor) Execute(ctx context.Context, f Op) error {
permanent.go#L78: func (*untilPermanentExecutor) Execute(ctx context.Context, f Op) error {
retry.go#L45: func (r *RetryExecutor) Execute(ctx context.Context, f Op) error {
schedule.go#L140: func (s *ScheduleExecutor) Execute(ctx context.Context, f Op) error {
watchdog.go#L44: func (w *WatchdogExecutor) Execute(ctx context.Context, f Op) error {
go.pact.im/x/grpcprocess
grpcprocess.go#L17: func(_ context.Context) error {
grpcprocess.go#L22: func(ctx context.Context) error {
go.pact.im/x/httpprocess
httpprocess.go#L22: func(ctx context.Context) error {
httpprocess.go#L24: srv.BaseContext = func(_ net.Listener) context.Context {
httpprocess.go#L53: func(ctx context.Context) error {
go.pact.im/x/netchan
netchan.go#L117: func (l *Listener) Dial(ctx context.Context) (net.Conn, error) {
go.pact.im/x/process
chain.go#L23: func (r *chainRunner) Run(ctx context.Context, callback Callback) error {
chain.go#L34: func (r *chainState) Run(ctx context.Context, callback Callback) error {
chain.go#L49: func (r *chainState) next(ctx context.Context) error {
parallel.go#L55: func (r *groupRunner) Run(ctx context.Context, callback Callback) error {
parallel.go#L65: child := func(ctx context.Context, callback Callback) error {
parallel.go#L84: startTasks[i] = func(ctx context.Context) error {
parallel.go#L97: stopTasks[i] = func(ctx context.Context) error {
process.go#L49: parent context.Context
process.go#L63: func NewProcess(ctx context.Context, runner Runner) *Process {
process.go#L98: func (p *Process) Start(ctx context.Context) error {
process.go#L99: var bgctx context.Context
process.go#L110: err := p.runner.Run(bgctx, func(bgctx context.Context) error {
process.go#L156: func (p *Process) Stop(ctx context.Context) error {
runner.go#L10: type Callback = func(context.Context) error
runner.go#L31: Run(ctx context.Context, callback Callback) error
runner.go#L35: type RunnerFunc func(context.Context, Callback) error
runner.go#L38: func (f RunnerFunc) Run(ctx context.Context, callback Callback) error {
runner.go#L52: func (*nopRunner) Run(ctx context.Context, callback Callback) error {
runner.go#L73: func (p *prefixedErrorRunner) Run(ctx context.Context, callback Callback) error {
task.go#L66: func Leaf(runInForeground, gracefulStop func(ctx context.Context) error) Runner {
task.go#L71: runInForeground func(ctx context.Context) error
task.go#L72: gracefulStop func(ctx context.Context) error
task.go#L75: func (r *leafRunner) Run(ctx context.Context, callback Callback) error {
task.go#L115: func StartStop(startInBackground, gracefulStop func(ctx context.Context) error) Runner {
task.go#L120: startInBackground func(ctx context.Context) error
task.go#L121: gracefulStop func(ctx context.Context) error
task.go#L124: func (r *startStopRunner) Run(ctx context.Context, callback Callback) error {
go.pact.im/x/slogtime
slogtime.go#L50: func (l *Logger) Enabled(ctx context.Context, level slog.Level) bool {
slogtime.go#L90: ctx context.Context,
go.pact.im/x/supervisor
builder.go#L12: type BuilderFunc[T process.Runner] func(context.Context) (T, error)
builder.go#L16: return func(_ context.Context) (T, error) {
builder.go#L23: func (f BuilderFunc[T]) Run(ctx context.Context, callback process.Callback) error {
builder.go#L70: func (b *Builder[T]) Run(ctx context.Context, callback process.Callback) error {
group.go#L17: ctx context.Context
group.go#L24: func NewGroup(ctx context.Context) *Group {
group.go#L29: func GroupBuilder(ctx context.Context) (*Group, error) {
group.go#L35: func (g *Group) Run(ctx context.Context, callback process.Callback) error {
group.go#L86: atExit(p.Run(ctx, func(ctx context.Context) error {
supervisor.go#L39: Pre func(context.Context, *Supervisor) error
supervisor.go#L44: Post func(context.Context, *Supervisor) error
supervisor.go#L89: func (s *Supervisor) Run(ctx context.Context, callback process.Callback) error {
supervisor.go#L125: func (s *Supervisor) execute(ctx context.Context, intr *supervisorInterrupter) error {
supervisor.go#L126: err := s.exec.Execute(ctx, func(ctx context.Context) error {
supervisor.go#L131: err := s.runner.Run(ctx, func(ctx context.Context) error {
supervisor.go#L154: func (s *Supervisor) pre(ctx context.Context) error {
supervisor.go#L162: func (s *Supervisor) post(ctx context.Context) error {
go.pact.im/x/task
context.go#L11: return func(ctx context.Context) error {
executor.go#L14: Execute(ctx context.Context, cond CancelCondition, tasks ...Task) error
executor.go#L34: func (e *executor) Execute(ctx context.Context, cond CancelCondition, tasks ...Task) error {
task.go#L15: type Task func(ctx context.Context) error
task.go#L18: func (t Task) Run(ctx context.Context) error {
task.go#L24: return func(ctx context.Context) error {
task.go#L37: return func(ctx context.Context) error {
task.go#L64: return func(ctx context.Context) error {
go.uber.org/mock/gomock
controller.go#L143: func WithContext(ctx context.Context, t TestReporter) (*Controller, context.Context) {
golang.org/x/net/http2
client_conn_pool.go#L117: ctx context.Context
client_conn_pool.go#L124: func (p *clientConnPool) getStartDialLocked(ctx context.Context, addr string) *dialCall {
client_conn_pool.go#L139: func (c *dialCall) dial(ctx context.Context, addr string) {
server.go#L286: var ctx context.Context
server.go#L288: BaseContext() context.Context
server.go#L326: Context context.Context
server.go#L352: func (o *ServeConnOpts) context() context.Context {
server.go#L540: func serverConnBaseContext(c net.Conn, opts *ServeConnOpts) (ctx context.Context, cancel func()) {
server.go#L564: baseCtx context.Context
server.go#L651: ctx context.Context
transport.go#L74: DialTLSContext func(ctx context.Context, network, addr string, cfg *tls.Config) (net.Conn, error)
transport.go#L399: ctx context.Context
transport.go#L709: func (t *Transport) dialClientConn(ctx context.Context, addr string, singleUse bool) (*ClientConn, error) {
transport.go#L738: func (t *Transport) dialTLS(ctx context.Context, network, addr string, tlsCfg *tls.Config) (net.Conn, error) {
transport.go#L1132: func (cc *ClientConn) Shutdown(ctx context.Context) error {
transport.go#L2928: func (cc *ClientConn) Ping(ctx context.Context) error {
transport.go#L3223: func (t *Transport) dialTLSWithContext(ctx context.Context, network, addr string, cfg *tls.Config) (*tls.Conn, error) {
golang.org/x/net/internal/httpcommon
request.go#L64: func EncodeHeaders(ctx context.Context, param EncodeHeadersParam, headerf func(name, value string)) (res EncodeHeadersResult, _ error) {
golang.org/x/net/trace
trace.go#L136: func NewContext(ctx context.Context, tr Trace) context.Context {
trace.go#L141: func FromContext(ctx context.Context) (tr Trace, ok bool) {
golang.org/x/sync/errgroup
errgroup.go#L48: func WithContext(ctx context.Context) (*Group, context.Context) {
golang.org/x/tools/go/packages
golist.go#L81: ctx context.Context
golist.go#L1055: func getSizesForArgs(ctx context.Context, inv gocommand.Invocation, gocmdRunner *gocommand.Runner) (string, string, error) {
packages.go#L160: Context context.Context
golang.org/x/tools/internal/event
event.go#L17: type Exporter func(context.Context, core.Event, label.Map) context.Context
event.go#L28: func Log(ctx context.Context, message string, labels ...label.Label) {
event.go#L44: func Error(ctx context.Context, message string, err error, labels ...label.Label) {
event.go#L60: func Metric(ctx context.Context, labels ...label.Label) {
event.go#L74: func Label(ctx context.Context, labels ...label.Label) context.Context {
event.go#L90: func Start(ctx context.Context, name string, labels ...label.Label) (context.Context, func()) {
event.go#L116: func Detach(ctx context.Context) context.Context {
golang.org/x/tools/internal/event/core
export.go#L18: type Exporter func(context.Context, Event, label.Map) context.Context
export.go#L41: func deliver(ctx context.Context, exporter Exporter, ev Event) context.Context {
export.go#L49: func Export(ctx context.Context, ev Event) context.Context {
export.go#L62: func ExportPair(ctx context.Context, begin, end Event) (context.Context, func()) {
fast.go#L16: func Log1(ctx context.Context, message string, t1 label.Label) {
fast.go#L25: func Log2(ctx context.Context, message string, t1 label.Label, t2 label.Label) {
fast.go#L34: func Metric1(ctx context.Context, t1 label.Label) context.Context {
fast.go#L42: func Metric2(ctx context.Context, t1, t2 label.Label) context.Context {
fast.go#L53: func Start1(ctx context.Context, name string, t1 label.Label) (context.Context, func()) {
fast.go#L67: func Start2(ctx context.Context, name string, t1, t2 label.Label) (context.Context, func()) {
golang.org/x/tools/internal/gocommand
invoke.go#L70: func (runner *Runner) Run(ctx context.Context, inv Invocation) (*bytes.Buffer, error) {
invoke.go#L80: func (runner *Runner) RunPiped(ctx context.Context, inv Invocation, stdout, stderr io.Writer) error {
invoke.go#L91: func (runner *Runner) RunRaw(ctx context.Context, inv Invocation) (*bytes.Buffer, *bytes.Buffer, error, error) {
invoke.go#L114: func (runner *Runner) runConcurrent(ctx context.Context, inv Invocation) (*bytes.Buffer, *bytes.Buffer, error, error) {
invoke.go#L129: func (runner *Runner) runPiped(ctx context.Context, inv Invocation, stdout, stderr io.Writer) (error, error) {
invoke.go#L186: func (i *Invocation) runWithFriendlyError(ctx context.Context, stdout, stderr io.Writer) (friendlyError error, rawError error) {
invoke.go#L209: func (i *Invocation) run(ctx context.Context, stdout, stderr io.Writer) error {
invoke.go#L296: func runCmdContext(ctx context.Context, cmd *exec.Cmd) (err error) {
vendor.go#L41: func VendorEnabled(ctx context.Context, inv Invocation, r *Runner) (bool, *ModuleJSON, error) {
vendor.go#L83: func getMainModuleAnd114(ctx context.Context, inv Invocation, r *Runner) (*ModuleJSON, bool, error) {
vendor.go#L115: func WorkspaceVendorEnabled(ctx context.Context, inv Invocation, r *Runner) (bool, []*ModuleJSON, error) {
vendor.go#L135: func getWorkspaceMainModules(ctx context.Context, inv Invocation, r *Runner) ([]*ModuleJSON, error) {
version.go#L23: func GoVersion(ctx context.Context, inv Invocation, r *Runner) (int, error) {
version.go#L52: func GoVersionOutput(ctx context.Context, inv Invocation, r *Runner) (string, error) {
google.golang.org/grpc
balancer_wrapper.go#L42: noOpRegisterHealthListenerFn = func(_ context.Context, listener func(balancer.SubConnState)) func() {
balancer_wrapper.go#L114: uccs := func(ctx context.Context) {
balancer_wrapper.go#L145: ccb.serializer.TrySchedule(func(ctx context.Context) {
balancer_wrapper.go#L161: ccb.serializer.TrySchedule(func(context.Context) {
balancer_wrapper.go#L173: ccb.serializer.TrySchedule(func(ctx context.Context) {
balancer_wrapper.go#L309: acbw.ccb.serializer.TrySchedule(func(ctx context.Context) {
balancer_wrapper.go#L365: func (acbw *acBalancerWrapper) NewStream(ctx context.Context, desc *StreamDesc, method string, opts ...CallOption) (ClientStream, error) {
balancer_wrapper.go#L376: func (acbw *acBalancerWrapper) Invoke(ctx context.Context, method string, args any, reply any, opts ...CallOption) error {
balancer_wrapper.go#L438: type healthProducerRegisterFn = func(context.Context, balancer.SubConn, string, func(balancer.SubConnState)) func()
balancer_wrapper.go#L449: func (acbw *acBalancerWrapper) healthListenerRegFn() func(context.Context, func(balancer.SubConnState)) func() {
balancer_wrapper.go#L462: return func(ctx context.Context, listener func(balancer.SubConnState)) func() {
balancer_wrapper.go#L492: acbw.ccb.serializer.TrySchedule(func(ctx context.Context) {
balancer_wrapper.go#L505: acbw.ccb.serializer.TrySchedule(func(ctx context.Context) {
call.go#L29: func (cc *ClientConn) Invoke(ctx context.Context, method string, args, reply any, opts ...CallOption) error {
call.go#L59: func Invoke(ctx context.Context, method string, args, reply any, cc *ClientConn, opts ...CallOption) error {
call.go#L65: func invoke(ctx context.Context, method string, req, reply any, cc *ClientConn, opts ...CallOption) error {
clientconn.go#L239: func DialContext(ctx context.Context, target string, opts ...DialOption) (conn *ClientConn, err error) {
clientconn.go#L476: chainedInt = func(ctx context.Context, method string, req, reply any, cc *ClientConn, invoker UnaryInvoker, opts ...CallOption) error {
clientconn.go#L488: return func(ctx context.Context, method string, req, reply any, cc *ClientConn, opts ...CallOption) error {
clientconn.go#L507: chainedInt = func(ctx context.Context, desc *StreamDesc, cc *ClientConn, method string, streamer Streamer, opts ...CallOption) (ClientStream, error) {
clientconn.go#L519: return func(ctx context.Context, desc *StreamDesc, cc *ClientConn, method string, opts ...CallOption) (ClientStream, error) {
clientconn.go#L526: func newConnectivityStateManager(ctx context.Context, channel *channelz.Channel) *connectivityStateManager {
clientconn.go#L592: Invoke(ctx context.Context, method string, args any, reply any, opts ...CallOption) error
clientconn.go#L594: NewStream(ctx context.Context, desc *StreamDesc, method string, opts ...CallOption) (ClientStream, error)
clientconn.go#L613: ctx context.Context // Initialized using the background context at dial time.
clientconn.go#L654: func (cc *ClientConn) WaitForStateChange(ctx context.Context, sourceState connectivity.State) bool {
clientconn.go#L703: func (cc *ClientConn) waitForResolvedAddrs(ctx context.Context) (bool, error) {
clientconn.go#L1187: ctx context.Context
clientconn.go#L1326: func (ac *addrConn) tryAllAddrs(ctx context.Context, addrs []resolver.Address, connectDeadline time.Time) error {
clientconn.go#L1364: func (ac *addrConn) createTransport(ctx context.Context, addr resolver.Address, copts transport.ConnectOptions, connectDeadline time.Time) error {
clientconn.go#L1456: func (ac *addrConn) startHealthCheck(ctx context.Context) {
dialoptions.go#L484: func WithContextDialer(f func(context.Context, string) (net.Conn, error)) DialOption {
dialoptions.go#L499: func(ctx context.Context, addr string) (net.Conn, error) {
interceptor.go#L26: type UnaryInvoker func(ctx context.Context, method string, req, reply any, cc *ClientConn, opts ...CallOption) error
interceptor.go#L43: type UnaryClientInterceptor func(ctx context.Context, method string, req, reply any, cc *ClientConn, invoker UnaryInvoker, opts ...CallOption) error
interceptor.go#L46: type Streamer func(ctx context.Context, desc *StreamDesc, cc *ClientConn, method string, opts ...CallOption) (ClientStream, error)
interceptor.go#L63: type StreamClientInterceptor func(ctx context.Context, desc *StreamDesc, cc *ClientConn, method string, streamer Streamer, opts ...CallOption) (ClientStream, error)
interceptor.go#L81: type UnaryHandler func(ctx context.Context, req any) (any, error)
interceptor.go#L87: type UnaryServerInterceptor func(ctx context.Context, req any, info *UnaryServerInfo, handler UnaryHandler) (resp any, err error)
picker_wrapper.go#L105: func (pw *pickerWrapper) pick(ctx context.Context, failfast bool, info balancer.PickInfo) (pick, error) {
resolver_wrapper.go#L70: ccr.serializer.TrySchedule(func(ctx context.Context) {
resolver_wrapper.go#L99: ccr.serializer.TrySchedule(func(ctx context.Context) {
resolver_wrapper.go#L116: ccr.serializer.TrySchedule(func(context.Context) {
rpc_util.go#L968: func newContextWithRPCInfo(ctx context.Context, failfast bool, codec baseCodec, cp Compressor, comp encoding.Compressor) context.Context {
rpc_util.go#L979: func rpcInfoFromContext(ctx context.Context) (s *rpcInfo, ok bool) {
server.go#L96: type MethodHandler func(srv any, ctx context.Context, dec func(any) error, interceptor UnaryServerInterceptor) (any, error)
server.go#L1036: func (s *Server) serveStreams(ctx context.Context, st transport.ServerTransport, rawConn net.Conn) {
server.go#L1171: func (s *Server) sendResponse(ctx context.Context, stream *transport.ServerStream, msg any, cp Compressor, opts *transport.WriteOptions, comp encoding.Compressor) error {
server.go#L1233: return func(ctx context.Context, req any, info *UnaryServerInfo, handler UnaryHandler) (any, error) {
server.go#L1242: return func(ctx context.Context, req any) (any, error) {
server.go#L1247: func (s *Server) processUnaryRPC(ctx context.Context, stream *transport.ServerStream, info *serviceInfo, md *MethodDesc, trInfo *traceInfo) (err error) {
server.go#L1578: func (s *Server) processStreamingRPC(ctx context.Context, stream *transport.ServerStream, info *serviceInfo, sd *StreamDesc, trInfo *traceInfo) (err error) {
server.go#L1887: func NewContextWithServerTransportStream(ctx context.Context, stream ServerTransportStream) context.Context {
server.go#L1917: func ServerTransportStreamFromContext(ctx context.Context) ServerTransportStream {
server.go#L2031: func serverFromContext(ctx context.Context) *Server {
server.go#L2037: func contextWithServer(ctx context.Context, server *Server) context.Context {
server.go#L2086: func SetHeader(ctx context.Context, md metadata.MD) error {
server.go#L2105: func SendHeader(ctx context.Context, md metadata.MD) error {
server.go#L2139: func SetSendCompressor(ctx context.Context, name string) error {
server.go#L2161: func ClientSupportedCompressors(ctx context.Context) ([]string, error) {
server.go#L2176: func SetTrailer(ctx context.Context, md metadata.MD) error {
server.go#L2189: func Method(ctx context.Context) (string, bool) {
stream.go#L51: var metadataFromOutgoingContextRaw = internal.FromOutgoingContextRaw.(func(context.Context) (metadata.MD, [][]string, bool))
stream.go#L83: Context() context.Context
stream.go#L112: Context() context.Context
stream.go#L164: func (cc *ClientConn) NewStream(ctx context.Context, desc *StreamDesc, method string, opts ...CallOption) (ClientStream, error) {
stream.go#L176: func NewClientStream(ctx context.Context, desc *StreamDesc, cc *ClientConn, method string, opts ...CallOption) (ClientStream, error) {
stream.go#L180: func newClientStream(ctx context.Context, desc *StreamDesc, cc *ClientConn, method string, opts ...CallOption) (_ ClientStream, err error) {
stream.go#L222: newStream := func(ctx context.Context, done func()) (iresolver.ClientStream, error) {
stream.go#L248: newStream = func(ctx context.Context, done func()) (iresolver.ClientStream, error) {
stream.go#L261: func newClientStreamWithParams(ctx context.Context, desc *StreamDesc, cc *ClientConn, method string, mc serviceconfig.MethodConfig, onCommit, doneFunc func(), nameResolutionDelayed bool, opts ...CallOption) (_ iresolver.ClientStream, err error) {
stream.go#L554: ctx context.Context // the application's context, wrapped by stats/tracing
stream.go#L598: ctx context.Context
stream.go#L767: func (cs *clientStream) Context() context.Context {
stream.go#L1247: func newNonRetryClientStream(ctx context.Context, desc *StreamDesc, method string, t transport.ClientTransport, ac *addrConn, opts ...CallOption) (_ ClientStream, err error) {
stream.go#L1360: ctx context.Context
stream.go#L1403: func (as *addrConnStream) Context() context.Context {
stream.go#L1553: Context() context.Context
stream.go#L1585: ctx context.Context
stream.go#L1618: func (ss *serverStream) Context() context.Context {
trace_withtrace.go#L33: func newTraceContext(ctx context.Context, tr traceLog) context.Context {
google.golang.org/grpc/balancer
balancer.go#L203: Dialer func(context.Context, string) (net.Conn, error)
balancer.go#L245: Ctx context.Context
google.golang.org/grpc/credentials
credentials.go#L49: GetRequestMetadata(ctx context.Context, uri ...string) (map[string]string, error)
credentials.go#L173: ClientHandshake(context.Context, string, net.Conn) (net.Conn, AuthInfo, error)
credentials.go#L246: func RequestInfoFromContext(ctx context.Context) (ri RequestInfo, ok bool) {
credentials.go#L261: func NewContextWithRequestInfo(ctx context.Context, ri RequestInfo) context.Context {
credentials.go#L281: func ClientHandshakeInfoFromContext(ctx context.Context) ClientHandshakeInfo {
tls.go#L110: func (c *tlsCreds) ClientHandshake(ctx context.Context, authority string, rawConn net.Conn) (_ net.Conn, _ AuthInfo, err error) {
google.golang.org/grpc/credentials/insecure
insecure.go#L43: func (insecureTC) ClientHandshake(_ context.Context, _ string, conn net.Conn) (net.Conn, credentials.AuthInfo, error) {
google.golang.org/grpc/health
client.go#L38: backoffFunc = func(ctx context.Context, retries int) bool {
client.go#L59: func clientHealthCheck(ctx context.Context, newStream func(string) (any, error), setConnectivityState func(connectivity.State, error), service string) error {
producer.go#L66: func registerClientSideHealthCheckListener(ctx context.Context, sc balancer.SubConn, serviceName string, listener func(balancer.SubConnState)) func() {
producer.go#L83: func (p *healthServiceProducer) startHealthCheck(ctx context.Context, sc balancer.SubConn, serviceName string, listener func(balancer.SubConnState)) {
server.go#L61: func (s *Server) Check(_ context.Context, in *healthpb.HealthCheckRequest) (*healthpb.HealthCheckResponse, error) {
server.go#L73: func (s *Server) List(_ context.Context, _ *healthpb.HealthListRequest) (*healthpb.HealthListResponse, error) {
google.golang.org/grpc/health/grpc_health_v1
health_grpc.pb.go#L59: Check(ctx context.Context, in *HealthCheckRequest, opts ...grpc.CallOption) (*HealthCheckResponse, error)
health_grpc.pb.go#L71: List(ctx context.Context, in *HealthListRequest, opts ...grpc.CallOption) (*HealthListResponse, error)
health_grpc.pb.go#L87: Watch(ctx context.Context, in *HealthCheckRequest, opts ...grpc.CallOption) (grpc.ServerStreamingClient[HealthCheckResponse], error)
health_grpc.pb.go#L98: func (c *healthClient) Check(ctx context.Context, in *HealthCheckRequest, opts ...grpc.CallOption) (*HealthCheckResponse, error) {
health_grpc.pb.go#L108: func (c *healthClient) List(ctx context.Context, in *HealthListRequest, opts ...grpc.CallOption) (*HealthListResponse, error) {
health_grpc.pb.go#L118: func (c *healthClient) Watch(ctx context.Context, in *HealthCheckRequest, opts ...grpc.CallOption) (grpc.ServerStreamingClient[HealthCheckResponse], error) {
health_grpc.pb.go#L152: Check(context.Context, *HealthCheckRequest) (*HealthCheckResponse, error)
health_grpc.pb.go#L164: List(context.Context, *HealthListRequest) (*HealthListResponse, error)
health_grpc.pb.go#L190: func (UnimplementedHealthServer) Check(context.Context, *HealthCheckRequest) (*HealthCheckResponse, error) {
health_grpc.pb.go#L193: func (UnimplementedHealthServer) List(context.Context, *HealthListRequest) (*HealthListResponse, error) {
health_grpc.pb.go#L219: func _Health_Check_Handler(srv interface{}, ctx context.Context, dec func(interface{}) error, interceptor grpc.UnaryServerInterceptor) (interface{}, error) {
health_grpc.pb.go#L231: handler := func(ctx context.Context, req interface{}) (interface{}, error) {
health_grpc.pb.go#L237: func _Health_List_Handler(srv interface{}, ctx context.Context, dec func(interface{}) error, interceptor grpc.UnaryServerInterceptor) (interface{}, error) {
health_grpc.pb.go#L249: handler := func(ctx context.Context, req interface{}) (interface{}, error) {
google.golang.org/grpc/internal
internal.go#L258: type HealthChecker func(ctx context.Context, newStream func(string) (any, error), setConnectivityState func(connectivity.State, error), serviceName string) error
google.golang.org/grpc/internal/backoff
backoff.go#L86: func RunF(ctx context.Context, f func() error, backoff func(int) time.Duration) {
google.golang.org/grpc/internal/binarylog
method_logger.go#L57: Log(context.Context, LogEntryConfig)
method_logger.go#L109: func (ml *TruncatingMethodLogger) Log(_ context.Context, c LogEntryConfig) {
google.golang.org/grpc/internal/credentials
credentials.go#L28: func ClientHandshakeInfoFromContext(ctx context.Context) any {
credentials.go#L33: func NewClientHandshakeInfoContext(ctx context.Context, chi any) context.Context {
google.golang.org/grpc/internal/grpcsync
callback_serializer.go#L47: func NewCallbackSerializer(ctx context.Context) *CallbackSerializer {
callback_serializer.go#L63: func (cs *CallbackSerializer) TrySchedule(f func(ctx context.Context)) {
callback_serializer.go#L74: func (cs *CallbackSerializer) ScheduleOr(f func(ctx context.Context), onFailure func()) {
callback_serializer.go#L80: func (cs *CallbackSerializer) run(ctx context.Context) {
callback_serializer.go#L94: cb.(func(context.Context))(ctx)
callback_serializer.go#L104: cb.(func(context.Context))(ctx)
pubsub.go#L57: func NewPubSub(ctx context.Context) *PubSub {
pubsub.go#L80: ps.cs.TrySchedule(func(context.Context) {
pubsub.go#L106: ps.cs.TrySchedule(func(context.Context) {
google.golang.org/grpc/internal/grpcutil
metadata.go#L30: func WithExtraMetadata(ctx context.Context, md metadata.MD) context.Context {
metadata.go#L37: func ExtraMetadata(ctx context.Context) (md metadata.MD, ok bool) {
google.golang.org/grpc/internal/resolver
config_selector.go#L44: Context context.Context
config_selector.go#L52: Context context.Context
config_selector.go#L76: Context() context.Context
config_selector.go#L117: NewStream(ctx context.Context, ri RPCInfo, done func(), newStream func(ctx context.Context, done func()) (ClientStream, error)) (ClientStream, error)
config_selector.go#L125: AllowRPC(ctx context.Context) error // TODO: Make this a real interceptor for filters such as rate limiting.
google.golang.org/grpc/internal/resolver/dns
dns_resolver.go#L85: var addressDialer = func(address string) func(context.Context, string, string) (net.Conn, error) {
dns_resolver.go#L86: return func(ctx context.Context, network, _ string) (net.Conn, error) {
dns_resolver.go#L171: ctx context.Context
dns_resolver.go#L240: func (d *dnsResolver) lookupSRV(ctx context.Context) ([]resolver.Address, error) {
dns_resolver.go#L290: func (d *dnsResolver) lookupTXT(ctx context.Context) *serviceconfig.ParseResult {
dns_resolver.go#L318: func (d *dnsResolver) lookupHost(ctx context.Context) ([]resolver.Address, error) {
google.golang.org/grpc/internal/resolver/dns/internal
internal.go#L33: LookupHost(ctx context.Context, host string) (addrs []string, err error)
internal.go#L34: LookupSRV(ctx context.Context, service, proto, name string) (cname string, addrs []*net.SRV, err error)
internal.go#L35: LookupTXT(ctx context.Context, name string) (txts []string, err error)
internal.go#L76: AddressDialer func(address string) func(context.Context, string, string) (net.Conn, error)
google.golang.org/grpc/internal/stats
labels.go#L33: func GetLabels(ctx context.Context) *Labels {
labels.go#L39: func SetLabels(ctx context.Context, labels *Labels) context.Context {
google.golang.org/grpc/internal/transport
handler_server.go#L390: func (ht *serverHandlerTransport) HandleStreams(ctx context.Context, startStream func(*ServerStream)) {
http2_client.go#L66: var metadataFromOutgoingContextRaw = internal.FromOutgoingContextRaw.(func(context.Context) (metadata.MD, [][]string, bool))
http2_client.go#L71: ctx context.Context
http2_client.go#L157: func dial(ctx context.Context, fn func(context.Context, string) (net.Conn, error), addr resolver.Address, grpcUA string) (net.Conn, error) {
http2_client.go#L206: func NewHTTP2Client(connectCtx, ctx context.Context, addr resolver.Address, opts ConnectOptions, onClose func(GoAwayReason)) (_ ClientTransport, err error) {
http2_client.go#L481: func (t *http2Client) newStream(ctx context.Context, callHdr *CallHdr) *ClientStream {
http2_client.go#L539: func (t *http2Client) createHeaderFields(ctx context.Context, callHdr *CallHdr) ([]hpack.HeaderField, error) {
http2_client.go#L655: func (t *http2Client) getTrAuthData(ctx context.Context, audience string) (map[string]string, error) {
http2_client.go#L682: func (t *http2Client) getCallAuthData(ctx context.Context, audience string, callHdr *CallHdr) (map[string]string, error) {
http2_client.go#L738: func (t *http2Client) NewStream(ctx context.Context, callHdr *CallHdr) (*ClientStream, error) {
http2_server.go#L368: func (t *http2Server) operateHeaders(ctx context.Context, frame *http2.MetaHeadersFrame, handle func(*ServerStream)) error {
http2_server.go#L670: func (t *http2Server) HandleStreams(ctx context.Context, handle func(*ServerStream)) {
http2_server.go#L1498: func GetConnection(ctx context.Context) net.Conn {
http2_server.go#L1506: func SetConnection(ctx context.Context, conn net.Conn) context.Context {
proxy.go#L57: func doHTTPConnectHandshake(ctx context.Context, conn net.Conn, grpcUA string, opts proxyattributes.Options) (_ net.Conn, err error) {
proxy.go#L102: func proxyDial(ctx context.Context, addr resolver.Address, grpcUA string, opts proxyattributes.Options) (net.Conn, error) {
proxy.go#L110: func sendHTTPRequest(ctx context.Context, req *http.Request, conn net.Conn) error {
server_stream.go#L122: func (s *ServerStream) SetContext(ctx context.Context) {
transport.go#L127: ctx context.Context
transport.go#L289: ctx context.Context // the associated context of the stream
transport.go#L332: func (s *Stream) Context() context.Context {
transport.go#L477: Dialer func(context.Context, string) (net.Conn, error)
transport.go#L569: NewStream(ctx context.Context, callHdr *CallHdr) (*ClientStream, error)
transport.go#L598: HandleStreams(context.Context, func(*ServerStream))
google.golang.org/grpc/metadata
metadata.go#L164: func NewIncomingContext(ctx context.Context, md MD) context.Context {
metadata.go#L172: func NewOutgoingContext(ctx context.Context, md MD) context.Context {
metadata.go#L179: func AppendToOutgoingContext(ctx context.Context, kv ...string) context.Context {
metadata.go#L197: func FromIncomingContext(ctx context.Context) (MD, bool) {
metadata.go#L216: func ValueFromIncomingContext(ctx context.Context, key string) []string {
metadata.go#L248: func fromOutgoingContextRaw(ctx context.Context) (MD, [][]string, bool) {
metadata.go#L260: func FromOutgoingContext(ctx context.Context) (MD, bool) {
google.golang.org/grpc/peer
peer.go#L75: func NewContext(ctx context.Context, p *Peer) context.Context {
peer.go#L80: func FromContext(ctx context.Context) (p *Peer, ok bool) {
google.golang.org/grpc/resolver
resolver.go#L175: Dialer func(context.Context, string) (net.Conn, error)
google.golang.org/grpc/stats
handlers.go#L57: TagRPC(context.Context, *RPCTagInfo) context.Context
handlers.go#L59: HandleRPC(context.Context, RPCStats)
handlers.go#L69: TagConn(context.Context, *ConnTagInfo) context.Context
handlers.go#L71: HandleConn(context.Context, ConnStats)
stats.go#L285: func SetTags(ctx context.Context, b []byte) context.Context {
stats.go#L292: func Tags(ctx context.Context) []byte {
stats.go#L305: func SetTrace(ctx context.Context, b []byte) context.Context {
stats.go#L312: func Trace(ctx context.Context) []byte {
google.golang.org/grpc/tap
tap.go#L62: type ServerInHandle func(ctx context.Context, info *Info) (context.Context, error)
log/slog
handler.go#L43: Enabled(context.Context, Level) bool
handler.go#L65: Handle(context.Context, Record) error
handler.go#L107: func (*defaultHandler) Enabled(_ context.Context, l Level) bool {
handler.go#L114: func (h *defaultHandler) Handle(ctx context.Context, r Record) error {
handler.go#L641: func (dh discardHandler) Enabled(context.Context, Level) bool { return false }
handler.go#L642: func (dh discardHandler) Handle(context.Context, Record) error { return nil }
json_handler.go#L46: func (h *JSONHandler) Enabled(_ context.Context, level Level) bool {
json_handler.go#L88: func (h *JSONHandler) Handle(_ context.Context, r Record) error {
logger.go#L164: func (l *Logger) Enabled(ctx context.Context, level Level) bool {
logger.go#L188: func (l *Logger) Log(ctx context.Context, level Level, msg string, args ...any) {
logger.go#L193: func (l *Logger) LogAttrs(ctx context.Context, level Level, msg string, attrs ...Attr) {
logger.go#L203: func (l *Logger) DebugContext(ctx context.Context, msg string, args ...any) {
logger.go#L213: func (l *Logger) InfoContext(ctx context.Context, msg string, args ...any) {
logger.go#L223: func (l *Logger) WarnContext(ctx context.Context, msg string, args ...any) {
logger.go#L233: func (l *Logger) ErrorContext(ctx context.Context, msg string, args ...any) {
logger.go#L240: func (l *Logger) log(ctx context.Context, level Level, msg string, args ...any) {
logger.go#L260: func (l *Logger) logAttrs(ctx context.Context, level Level, msg string, attrs ...Attr) {
logger.go#L285: func DebugContext(ctx context.Context, msg string, args ...any) {
logger.go#L295: func InfoContext(ctx context.Context, msg string, args ...any) {
logger.go#L305: func WarnContext(ctx context.Context, msg string, args ...any) {
logger.go#L315: func ErrorContext(ctx context.Context, msg string, args ...any) {
logger.go#L320: func Log(ctx context.Context, level Level, msg string, args ...any) {
logger.go#L325: func LogAttrs(ctx context.Context, level Level, msg string, attrs ...Attr) {
text_handler.go#L44: func (h *TextHandler) Enabled(_ context.Context, level Level) bool {
text_handler.go#L92: func (h *TextHandler) Handle(_ context.Context, r Record) error {
net
cgo_unix.go#L47: func doBlockingWithCtx[T any](ctx context.Context, lookupName string, blocking func() (T, error)) (T, error) {
cgo_unix.go#L80: func cgoLookupHost(ctx context.Context, name string) (hosts []string, err error) {
cgo_unix.go#L91: func cgoLookupPort(ctx context.Context, network, service string) (port int, err error) {
cgo_unix.go#L227: func cgoLookupIP(ctx context.Context, network, name string) (addrs []IPAddr, err error) {
cgo_unix.go#L246: func cgoLookupPTR(ctx context.Context, addr string) (names []string, err error) {
cgo_unix.go#L300: func cgoLookupCNAME(ctx context.Context, name string) (cname string, err error, completed bool) {
cgo_unix.go#L314: func resSearch(ctx context.Context, hostname string, rtype, class int) ([]dnsmessage.Resource, error) {
dial.go#L224: ControlContext func(ctx context.Context, network, address string, c syscall.RawConn) error
dial.go#L250: func (d *Dialer) deadline(ctx context.Context, now time.Time) (earliest time.Time) {
dial.go#L299: func parseNetwork(ctx context.Context, network string, needsProto bool) (afnet string, proto int, err error) {
dial.go#L334: func (r *Resolver) resolveAddrList(ctx context.Context, op, network, addr string, hint Addr) (addrList, error) {
dial.go#L493: testHookDialTCP func(ctx context.Context, net string, laddr, raddr *TCPAddr) (*TCPConn, error)
dial.go#L525: func (d *Dialer) DialContext(ctx context.Context, network, address string) (Conn, error) {
dial.go#L585: func (sd *sysDialer) dialParallel(ctx context.Context, primaries, fallbacks addrList) (Conn, error) {
dial.go#L601: startRacer := func(ctx context.Context, primary bool) {
dial.go#L659: func (sd *sysDialer) dialSerial(ctx context.Context, ras addrList) (Conn, error) {
dial.go#L703: func (sd *sysDialer) dialSingle(ctx context.Context, ra Addr) (c Conn, err error) {
dial.go#L804: func (lc *ListenConfig) Listen(ctx context.Context, network, address string) (Listener, error) {
dial.go#L841: func (lc *ListenConfig) ListenPacket(ctx context.Context, network, address string) (PacketConn, error) {
dnsclient_unix.go#L169: func (r *Resolver) exchange(ctx context.Context, server string, q dnsmessage.Question, timeout time.Duration, useTCP, ad bool) (dnsmessage.Parser, dnsmessage.Header, error) {
dnsclient_unix.go#L297: func (r *Resolver) tryOneName(ctx context.Context, cfg *dnsConfig, name string, qtype dnsmessage.Type) (dnsmessage.Parser, string, error) {
dnsclient_unix.go#L441: func (r *Resolver) lookup(ctx context.Context, name string, qtype dnsmessage.Type, conf *dnsConfig) (dnsmessage.Parser, string, error) {
dnsclient_unix.go#L565: func (r *Resolver) goLookupHostOrder(ctx context.Context, name string, order hostLookupOrder, conf *dnsConfig) (addrs []string, err error) {
dnsclient_unix.go#L604: func (r *Resolver) goLookupIP(ctx context.Context, network, host string, order hostLookupOrder, conf *dnsConfig) (addrs []IPAddr, err error) {
dnsclient_unix.go#L609: func (r *Resolver) goLookupIPCNAMEOrder(ctx context.Context, network, name string, order hostLookupOrder, conf *dnsConfig) (addrs []IPAddr, cname dnsmessage.Name, err error) {
dnsclient_unix.go#L821: func (r *Resolver) goLookupCNAME(ctx context.Context, host string, order hostLookupOrder, conf *dnsConfig) (string, error) {
dnsclient_unix.go#L827: func (r *Resolver) goLookupPTR(ctx context.Context, addr string, order hostLookupOrder, conf *dnsConfig) ([]string, error) {
fd_unix.go#L44: func (fd *netFD) connect(ctx context.Context, la, ra syscall.Sockaddr) (rsa syscall.Sockaddr, ret error) {
hook.go#L13: testHookDialTCP func(ctx context.Context, net string, laddr, raddr *TCPAddr) (*TCPConn, error)
hook.go#L16: ctx context.Context,
hook.go#L17: fn func(context.Context, string, string) ([]IPAddr, error),
iprawsock_posix.go#L115: func (sd *sysDialer) dialIP(ctx context.Context, laddr, raddr *IPAddr) (*IPConn, error) {
iprawsock_posix.go#L127: ctrlCtxFn = func(ctx context.Context, network, address string, c syscall.RawConn) error {
iprawsock_posix.go#L138: func (sl *sysListener) listenIP(ctx context.Context, laddr *IPAddr) (*IPConn, error) {
iprawsock_posix.go#L148: var ctrlCtxFn func(ctx context.Context, network, address string, c syscall.RawConn) error
iprawsock_posix.go#L150: ctrlCtxFn = func(ctx context.Context, network, address string, c syscall.RawConn) error {
ipsock.go#L249: func (r *Resolver) internetAddrList(ctx context.Context, net, addr string) (addrList, error) {
ipsock_posix.go#L159: func internetSocket(ctx context.Context, net string, laddr, raddr sockaddr, sotype, proto int, mode string, ctrlCtxFn func(context.Context, string, string, syscall.RawConn) error) (fd *netFD, err error) {
lookup.go#L161: Dial func(ctx context.Context, network, address string) (Conn, error)
lookup.go#L193: func (r *Resolver) LookupHost(ctx context.Context, host string) (addrs []string, err error) {
lookup.go#L220: func (r *Resolver) LookupIPAddr(ctx context.Context, host string) ([]IPAddr, error) {
lookup.go#L228: func (r *Resolver) LookupIP(ctx context.Context, network, host string) ([]IP, error) {
lookup.go#L258: func (r *Resolver) LookupNetIP(ctx context.Context, network, host string) ([]netip.Addr, error) {
lookup.go#L279: context.Context
lookup.go#L280: lookupValues context.Context
lookup.go#L283: var _ context.Context = (*onlyValuesCtx)(nil)
lookup.go#L299: func withUnexpiredValuesPreserved(lookupCtx context.Context) context.Context {
lookup.go#L305: func (r *Resolver) lookupIPAddr(ctx context.Context, network, host string) ([]IPAddr, error) {
lookup.go#L321: if alt, _ := ctx.Value(nettrace.LookupIPAltResolverKey{}).(func(context.Context, string, string) ([]IPAddr, error)); alt != nil {
lookup.go#L415: func (r *Resolver) LookupPort(ctx context.Context, network, service string) (port int, err error) {
lookup.go#L469: func (r *Resolver) LookupCNAME(ctx context.Context, host string) (string, error) {
lookup.go#L512: func (r *Resolver) LookupSRV(ctx context.Context, service, proto, name string) (string, []*SRV, error) {
lookup.go#L555: func (r *Resolver) LookupMX(ctx context.Context, name string) ([]*MX, error) {
lookup.go#L600: func (r *Resolver) LookupNS(ctx context.Context, name string) ([]*NS, error) {
lookup.go#L636: func (r *Resolver) LookupTXT(ctx context.Context, name string) ([]string, error) {
lookup.go#L662: func (r *Resolver) LookupAddr(ctx context.Context, addr string) ([]string, error) {
lookup.go#L687: func (r *Resolver) dial(ctx context.Context, network, server string) (Conn, error) {
lookup.go#L716: func (r *Resolver) goLookupSRV(ctx context.Context, service, proto, name string) (target string, srvs []*SRV, err error) {
lookup.go#L767: func (r *Resolver) goLookupMX(ctx context.Context, name string) ([]*MX, error) {
lookup.go#L811: func (r *Resolver) goLookupNS(ctx context.Context, name string) ([]*NS, error) {
lookup.go#L853: func (r *Resolver) goLookupTXT(ctx context.Context, name string) ([]string, error) {
lookup_unix.go#L48: func lookupProtocol(_ context.Context, name string) (int, error) {
lookup_unix.go#L53: func (r *Resolver) lookupHost(ctx context.Context, host string) (addrs []string, err error) {
lookup_unix.go#L61: func (r *Resolver) lookupIP(ctx context.Context, network, host string) (addrs []IPAddr, err error) {
lookup_unix.go#L70: func (r *Resolver) lookupPort(ctx context.Context, network, service string) (int, error) {
lookup_unix.go#L87: func (r *Resolver) lookupCNAME(ctx context.Context, name string) (string, error) {
lookup_unix.go#L97: func (r *Resolver) lookupSRV(ctx context.Context, service, proto, name string) (string, []*SRV, error) {
lookup_unix.go#L101: func (r *Resolver) lookupMX(ctx context.Context, name string) ([]*MX, error) {
lookup_unix.go#L105: func (r *Resolver) lookupNS(ctx context.Context, name string) ([]*NS, error) {
lookup_unix.go#L109: func (r *Resolver) lookupTXT(ctx context.Context, name string) ([]string, error) {
lookup_unix.go#L113: func (r *Resolver) lookupAddr(ctx context.Context, addr string) ([]string, error) {
mptcpsock_linux.go#L61: func (sd *sysDialer) dialMPTCP(ctx context.Context, laddr, raddr *TCPAddr) (*TCPConn, error) {
mptcpsock_linux.go#L77: func (sl *sysListener) listenMPTCP(ctx context.Context, laddr *TCPAddr) (*TCPListener, error) {
net.go#L809: func acquireThread(ctx context.Context) error {
sock_posix.go#L18: func socket(ctx context.Context, net string, family, sotype, proto int, ipv6only bool, laddr, raddr sockaddr, ctrlCtxFn func(context.Context, string, string, syscall.RawConn) error) (fd *netFD, err error) {
sock_posix.go#L92: func (fd *netFD) dial(ctx context.Context, laddr, raddr sockaddr, ctrlCtxFn func(context.Context, string, string, syscall.RawConn) error) error {
sock_posix.go#L150: func (fd *netFD) listenStream(ctx context.Context, laddr sockaddr, backlog int, ctrlCtxFn func(context.Context, string, string, syscall.RawConn) error) error {
sock_posix.go#L181: func (fd *netFD) listenDatagram(ctx context.Context, laddr sockaddr, ctrlCtxFn func(context.Context, string, string, syscall.RawConn) error) error {
tcpsock_posix.go#L64: func (sd *sysDialer) dialTCP(ctx context.Context, laddr, raddr *TCPAddr) (*TCPConn, error) {
tcpsock_posix.go#L74: func (sd *sysDialer) doDialTCP(ctx context.Context, laddr, raddr *TCPAddr) (*TCPConn, error) {
tcpsock_posix.go#L78: func (sd *sysDialer) doDialTCPProto(ctx context.Context, laddr, raddr *TCPAddr, proto int) (*TCPConn, error) {
tcpsock_posix.go#L81: ctrlCtxFn = func(ctx context.Context, network, address string, c syscall.RawConn) error {
tcpsock_posix.go#L178: func (sl *sysListener) listenTCP(ctx context.Context, laddr *TCPAddr) (*TCPListener, error) {
tcpsock_posix.go#L182: func (sl *sysListener) listenTCPProto(ctx context.Context, laddr *TCPAddr, proto int) (*TCPListener, error) {
tcpsock_posix.go#L183: var ctrlCtxFn func(ctx context.Context, network, address string, c syscall.RawConn) error
tcpsock_posix.go#L185: ctrlCtxFn = func(ctx context.Context, network, address string, c syscall.RawConn) error {
udpsock_posix.go#L205: func (sd *sysDialer) dialUDP(ctx context.Context, laddr, raddr *UDPAddr) (*UDPConn, error) {
udpsock_posix.go#L208: ctrlCtxFn = func(ctx context.Context, network, address string, c syscall.RawConn) error {
udpsock_posix.go#L219: func (sl *sysListener) listenUDP(ctx context.Context, laddr *UDPAddr) (*UDPConn, error) {
udpsock_posix.go#L220: var ctrlCtxFn func(ctx context.Context, network, address string, c syscall.RawConn) error
udpsock_posix.go#L222: ctrlCtxFn = func(ctx context.Context, network, address string, c syscall.RawConn) error {
udpsock_posix.go#L233: func (sl *sysListener) listenMulticastUDP(ctx context.Context, ifi *Interface, gaddr *UDPAddr) (*UDPConn, error) {
udpsock_posix.go#L234: var ctrlCtxFn func(ctx context.Context, network, address string, c syscall.RawConn) error
udpsock_posix.go#L236: ctrlCtxFn = func(ctx context.Context, network, address string, c syscall.RawConn) error {
unixsock_posix.go#L16: func unixSocket(ctx context.Context, net string, laddr, raddr sockaddr, mode string, ctxCtrlFn func(context.Context, string, string, syscall.RawConn) error) (*netFD, error) {
unixsock_posix.go#L157: func (sd *sysDialer) dialUnix(ctx context.Context, laddr, raddr *UnixAddr) (*UnixConn, error) {
unixsock_posix.go#L160: ctrlCtxFn = func(ctx context.Context, network, address string, c syscall.RawConn) error {
unixsock_posix.go#L219: func (sl *sysListener) listenUnix(ctx context.Context, laddr *UnixAddr) (*UnixListener, error) {
unixsock_posix.go#L220: var ctrlCtxFn func(ctx context.Context, network, address string, c syscall.RawConn) error
unixsock_posix.go#L222: ctrlCtxFn = func(ctx context.Context, network, address string, c syscall.RawConn) error {
unixsock_posix.go#L233: func (sl *sysListener) listenUnixgram(ctx context.Context, laddr *UnixAddr) (*UnixConn, error) {
unixsock_posix.go#L234: var ctrlCtxFn func(ctx context.Context, network, address string, c syscall.RawConn) error
unixsock_posix.go#L236: ctrlCtxFn = func(ctx context.Context, network, address string, c syscall.RawConn) error {
net/http
client.go#L307: func timeBeforeContextDeadline(t time.Time, ctx context.Context) bool {
h2_bundle.go#L843: ctx context.Context
h2_bundle.go#L850: func (p *http2clientConnPool) getStartDialLocked(ctx context.Context, addr string) *http2dialCall {
h2_bundle.go#L865: func (c *http2dialCall) dial(ctx context.Context, addr string) {
h2_bundle.go#L3827: ContextWithTimeout(ctx context.Context, d time.Duration) (context.Context, context.CancelFunc)
h2_bundle.go#L4266: var ctx context.Context
h2_bundle.go#L4268: BaseContext() context.Context
h2_bundle.go#L4306: Context context.Context
h2_bundle.go#L4332: func (o *http2ServeConnOpts) context() context.Context {
h2_bundle.go#L4517: func http2serverConnBaseContext(c net.Conn, opts *http2ServeConnOpts) (ctx context.Context, cancel func()) {
h2_bundle.go#L4541: baseCtx context.Context
h2_bundle.go#L4628: ctx context.Context
h2_bundle.go#L7353: DialTLSContext func(ctx context.Context, network, addr string, cfg *tls.Config) (net.Conn, error)
h2_bundle.go#L7514: func (t *http2Transport) contextWithTimeout(ctx context.Context, d time.Duration) (context.Context, context.CancelFunc) {
h2_bundle.go#L7722: ctx context.Context
h2_bundle.go#L8034: func (t *http2Transport) dialClientConn(ctx context.Context, addr string, singleUse bool) (*http2ClientConn, error) {
h2_bundle.go#L8063: func (t *http2Transport) dialTLS(ctx context.Context, network, addr string, tlsCfg *tls.Config) (net.Conn, error) {
h2_bundle.go#L8461: func (cc *http2ClientConn) Shutdown(ctx context.Context) error {
h2_bundle.go#L10262: func (cc *http2ClientConn) Ping(ctx context.Context) error {
h2_bundle.go#L10561: func (t *http2Transport) dialTLSWithContext(ctx context.Context, network, addr string, cfg *tls.Config) (*tls.Conn, error) {
request.go#L333: ctx context.Context
request.go#L352: func (r *Request) Context() context.Context {
request.go#L368: func (r *Request) WithContext(ctx context.Context) *Request {
request.go#L386: func (r *Request) Clone(ctx context.Context) *Request {
request.go#L889: func NewRequestWithContext(ctx context.Context, method, url string, body io.Reader) (*Request, error) {
server.go#L1012: func (c *conn) readRequest(ctx context.Context) (w *response, err error) {
server.go#L1933: func (c *conn) serve(ctx context.Context) {
server.go#L2158: ctx context.Context
server.go#L2163: func (h unencryptedHTTP2Request) BaseContext() context.Context { return h.ctx }
server.go#L2194: func (c *conn) maybeServeUnencryptedHTTP2(ctx context.Context) bool {
server.go#L3081: BaseContext func(net.Listener) context.Context
server.go#L3087: ConnContext func(ctx context.Context, c net.Conn) context.Context
server.go#L3179: func (s *Server) Shutdown(ctx context.Context) error {
server.go#L3835: testContext context.Context
server.go#L3991: ctx context.Context
server.go#L4000: func (h initALPNRequest) BaseContext() context.Context { return h.ctx }
socks_bundle.go#L27: func (d *socksDialer) connect(ctx context.Context, c net.Conn, address string) (_ net.Addr, ctxErr error) {
socks_bundle.go#L284: ProxyDial func(context.Context, string, string) (net.Conn, error)
socks_bundle.go#L294: Authenticate func(context.Context, io.ReadWriter, socksAuthMethod) error
socks_bundle.go#L307: func (d *socksDialer) DialContext(ctx context.Context, network, address string) (net.Conn, error) {
socks_bundle.go#L343: func (d *socksDialer) DialWithConn(ctx context.Context, c net.Conn, network, address string) (net.Addr, error) {
socks_bundle.go#L443: func (up *socksUsernamePassword) Authenticate(ctx context.Context, rw io.ReadWriter, auth socksAuthMethod) error {
transport.go#L133: OnProxyConnectResponse func(ctx context.Context, proxyURL *url.URL, connectReq *Request, connectRes *Response) error
transport.go#L143: DialContext func(ctx context.Context, network, addr string) (net.Conn, error)
transport.go#L167: DialTLSContext func(ctx context.Context, network, addr string) (net.Conn, error)
transport.go#L265: GetProxyConnectHeader func(ctx context.Context, proxyURL *url.URL, target string) (Header, error)
transport.go#L519: ctx context.Context // canceled when we are done with the request
transport.go#L743: func awaitLegacyCancel(ctx context.Context, cancel context.CancelCauseFunc, req *Request) {
transport.go#L1276: func (t *Transport) dial(ctx context.Context, network, addr string) (net.Conn, error) {
transport.go#L1311: ctx context.Context // context for dial, cleared after delivered or canceled
transport.go#L1332: func (w *wantConn) getCtxForDial() context.Context {
transport.go#L1471: func (t *Transport) customDialTLS(ctx context.Context, network, addr string) (conn net.Conn, err error) {
transport.go#L1684: func (pconn *persistConn) addTLS(ctx context.Context, name string, trace *httptrace.ClientTrace) error {
transport.go#L1739: func (t *Transport) dialConn(ctx context.Context, cm connectMethod) (pconn *persistConn, err error) {
transport_default_other.go#L14: func defaultTransportDialContext(dialer *net.Dialer) func(context.Context, string, string) (net.Conn, error) {
net/http/httptrace
trace.go#L24: func ContextClientTrace(ctx context.Context) *ClientTrace {
trace.go#L34: func WithClientTrace(ctx context.Context, trace *ClientTrace) context.Context {
net/http/internal/httpcommon
httpcommon.go#L215: func EncodeHeaders(ctx context.Context, param EncodeHeadersParam, headerf func(name, value string)) (res EncodeHeadersResult, _ error) {
os/exec
exec.go#L246: ctx context.Context
exec.go#L478: func CommandContext(ctx context.Context, name string, arg ...string) *Cmd {
runtime/pprof
label.go#L27: func labelValue(ctx context.Context) labelMap {
label.go#L60: func WithLabels(ctx context.Context, labels LabelSet) context.Context {
label.go#L132: func Label(ctx context.Context, key string) (string, bool) {
label.go#L144: func ForLabels(ctx context.Context, f func(key, value string) bool) {
runtime.go#L35: func SetGoroutineLabels(ctx context.Context) {
runtime.go#L47: func Do(ctx context.Context, labels LabelSet, f func(context.Context)) {
runtime/trace
annotation.go#L38: func NewTask(pctx context.Context, taskType string) (ctx context.Context, task *Task) {
annotation.go#L65: func fromContext(ctx context.Context) *Task {
annotation.go#L95: func Log(ctx context.Context, category, message string) {
annotation.go#L101: func Logf(ctx context.Context, category, format string, args ...any) {
annotation.go#L122: func WithRegion(ctx context.Context, regionType string, fn func()) {
annotation.go#L152: func StartRegion(ctx context.Context, regionType string) *Region {
testing
testing.go#L674: ctx context.Context
testing.go#L902: Context() context.Context
testing.go#L1494: func (c *common) Context() context.Context {