...

Package grpc

import "google.golang.org/grpc"
Overview
Index
Subdirectories

Overview ▾

Package grpc implements an RPC system called gRPC.

See grpc.io for more information about gRPC.

Index ▾

Constants
Variables
func ClientSupportedCompressors(ctx context.Context) ([]string, error)
func Code(err error) codes.Code
func ErrorDesc(err error) string
func Errorf(c codes.Code, format string, a ...any) error
func Invoke(ctx context.Context, method string, args, reply any, cc *ClientConn, opts ...CallOption) error
func Method(ctx context.Context) (string, bool)
func MethodFromServerStream(stream ServerStream) (string, bool)
func NewContextWithServerTransportStream(ctx context.Context, stream ServerTransportStream) context.Context
func SendHeader(ctx context.Context, md metadata.MD) error
func SetHeader(ctx context.Context, md metadata.MD) error
func SetSendCompressor(ctx context.Context, name string) error
func SetTrailer(ctx context.Context, md metadata.MD) error
type BackoffConfig
type BidiStreamingClient
type BidiStreamingServer
type CallOption
    func CallContentSubtype(contentSubtype string) CallOption
    func CallCustomCodec(codec Codec) CallOption
    func FailFast(failFast bool) CallOption
    func ForceCodec(codec encoding.Codec) CallOption
    func Header(md *metadata.MD) CallOption
    func MaxCallRecvMsgSize(bytes int) CallOption
    func MaxCallSendMsgSize(bytes int) CallOption
    func MaxRetryRPCBufferSize(bytes int) CallOption
    func OnFinish(onFinish func(err error)) CallOption
    func Peer(p *peer.Peer) CallOption
    func PerRPCCredentials(creds credentials.PerRPCCredentials) CallOption
    func StaticMethod() CallOption
    func Trailer(md *metadata.MD) CallOption
    func UseCompressor(name string) CallOption
    func WaitForReady(waitForReady bool) CallOption
type ClientConn
    func Dial(target string, opts ...DialOption) (*ClientConn, error)
    func DialContext(ctx context.Context, target string, opts ...DialOption) (conn *ClientConn, err error)
    func NewClient(target string, opts ...DialOption) (conn *ClientConn, err error)
    func (cc *ClientConn) CanonicalTarget() string
    func (cc *ClientConn) Close() error
    func (cc *ClientConn) Connect()
    func (cc *ClientConn) GetMethodConfig(method string) MethodConfig
    func (cc *ClientConn) GetState() connectivity.State
    func (cc *ClientConn) Invoke(ctx context.Context, method string, args, reply any, opts ...CallOption) error
    func (cc *ClientConn) NewStream(ctx context.Context, desc *StreamDesc, method string, opts ...CallOption) (ClientStream, error)
    func (cc *ClientConn) ResetConnectBackoff()
    func (cc *ClientConn) Target() string
    func (cc *ClientConn) WaitForStateChange(ctx context.Context, sourceState connectivity.State) bool
type ClientConnInterface
type ClientStream
    func NewClientStream(ctx context.Context, desc *StreamDesc, cc *ClientConn, method string, opts ...CallOption) (ClientStream, error)
type ClientStreamingClient
type ClientStreamingServer
type Codec
type Compressor
    func NewGZIPCompressor() Compressor
    func NewGZIPCompressorWithLevel(level int) (Compressor, error)
type CompressorCallOption
type ConnectParams
type ContentSubtypeCallOption
type CustomCodecCallOption
type Decompressor
    func NewGZIPDecompressor() Decompressor
type DialOption
    func FailOnNonTempDialError(f bool) DialOption
    func WithAuthority(a string) DialOption
    func WithBackoffConfig(b BackoffConfig) DialOption
    func WithBackoffMaxDelay(md time.Duration) DialOption
    func WithBlock() DialOption
    func WithChainStreamInterceptor(interceptors ...StreamClientInterceptor) DialOption
    func WithChainUnaryInterceptor(interceptors ...UnaryClientInterceptor) DialOption
    func WithChannelzParentID(c channelz.Identifier) DialOption
    func WithCodec(c Codec) DialOption
    func WithCompressor(cp Compressor) DialOption
    func WithConnectParams(p ConnectParams) DialOption
    func WithContextDialer(f func(context.Context, string) (net.Conn, error)) DialOption
    func WithCredentialsBundle(b credentials.Bundle) DialOption
    func WithDecompressor(dc Decompressor) DialOption
    func WithDefaultCallOptions(cos ...CallOption) DialOption
    func WithDefaultServiceConfig(s string) DialOption
    func WithDialer(f func(string, time.Duration) (net.Conn, error)) DialOption
    func WithDisableHealthCheck() DialOption
    func WithDisableRetry() DialOption
    func WithDisableServiceConfig() DialOption
    func WithIdleTimeout(d time.Duration) DialOption
    func WithInitialConnWindowSize(s int32) DialOption
    func WithInitialWindowSize(s int32) DialOption
    func WithInsecure() DialOption
    func WithKeepaliveParams(kp keepalive.ClientParameters) DialOption
    func WithMaxHeaderListSize(s uint32) DialOption
    func WithMaxMsgSize(s int) DialOption
    func WithNoProxy() DialOption
    func WithPerRPCCredentials(creds credentials.PerRPCCredentials) DialOption
    func WithReadBufferSize(s int) DialOption
    func WithRecvBufferPool(bufferPool SharedBufferPool) DialOption
    func WithResolvers(rs ...resolver.Builder) DialOption
    func WithReturnConnectionError() DialOption
    func WithSharedWriteBuffer(val bool) DialOption
    func WithStatsHandler(h stats.Handler) DialOption
    func WithStreamInterceptor(f StreamClientInterceptor) DialOption
    func WithTimeout(d time.Duration) DialOption
    func WithTransportCredentials(creds credentials.TransportCredentials) DialOption
    func WithUnaryInterceptor(f UnaryClientInterceptor) DialOption
    func WithUserAgent(s string) DialOption
    func WithWriteBufferSize(s int) DialOption
type EmptyCallOption
type EmptyDialOption
type EmptyServerOption
type FailFastCallOption
type ForceCodecCallOption
type GenericClientStream
    func (x *GenericClientStream[Req, Res]) CloseAndRecv() (*Res, error)
    func (x *GenericClientStream[Req, Res]) Recv() (*Res, error)
    func (x *GenericClientStream[Req, Res]) Send(m *Req) error
type GenericServerStream
    func (x *GenericServerStream[Req, Res]) Recv() (*Req, error)
    func (x *GenericServerStream[Req, Res]) Send(m *Res) error
    func (x *GenericServerStream[Req, Res]) SendAndClose(m *Res) error
type HeaderCallOption
type MaxHeaderListSizeDialOption
type MaxHeaderListSizeServerOption
type MaxRecvMsgSizeCallOption
type MaxRetryRPCBufferSizeCallOption
type MaxSendMsgSizeCallOption
type MethodConfig
type MethodDesc
type MethodInfo
type OnFinishCallOption
type PeerCallOption
type PerRPCCredsCallOption
type PreparedMsg
    func (p *PreparedMsg) Encode(s Stream, msg any) error
type Server
    func NewServer(opt ...ServerOption) *Server
    func (s *Server) GetServiceInfo() map[string]ServiceInfo
    func (s *Server) GracefulStop()
    func (s *Server) RegisterService(sd *ServiceDesc, ss any)
    func (s *Server) Serve(lis net.Listener) error
    func (s *Server) ServeHTTP(w http.ResponseWriter, r *http.Request)
    func (s *Server) Stop()
type ServerOption
    func ChainStreamInterceptor(interceptors ...StreamServerInterceptor) ServerOption
    func ChainUnaryInterceptor(interceptors ...UnaryServerInterceptor) ServerOption
    func ConnectionTimeout(d time.Duration) ServerOption
    func Creds(c credentials.TransportCredentials) ServerOption
    func CustomCodec(codec Codec) ServerOption
    func ForceServerCodec(codec encoding.Codec) ServerOption
    func HeaderTableSize(s uint32) ServerOption
    func InTapHandle(h tap.ServerInHandle) ServerOption
    func InitialConnWindowSize(s int32) ServerOption
    func InitialWindowSize(s int32) ServerOption
    func KeepaliveEnforcementPolicy(kep keepalive.EnforcementPolicy) ServerOption
    func KeepaliveParams(kp keepalive.ServerParameters) ServerOption
    func MaxConcurrentStreams(n uint32) ServerOption
    func MaxHeaderListSize(s uint32) ServerOption
    func MaxMsgSize(m int) ServerOption
    func MaxRecvMsgSize(m int) ServerOption
    func MaxSendMsgSize(m int) ServerOption
    func NumStreamWorkers(numServerWorkers uint32) ServerOption
    func RPCCompressor(cp Compressor) ServerOption
    func RPCDecompressor(dc Decompressor) ServerOption
    func ReadBufferSize(s int) ServerOption
    func RecvBufferPool(bufferPool SharedBufferPool) ServerOption
    func SharedWriteBuffer(val bool) ServerOption
    func StatsHandler(h stats.Handler) ServerOption
    func StreamInterceptor(i StreamServerInterceptor) ServerOption
    func UnaryInterceptor(i UnaryServerInterceptor) ServerOption
    func UnknownServiceHandler(streamHandler StreamHandler) ServerOption
    func WaitForHandlers(w bool) ServerOption
    func WriteBufferSize(s int) ServerOption
type ServerStream
type ServerStreamingClient
type ServerStreamingServer
type ServerTransportStream
    func ServerTransportStreamFromContext(ctx context.Context) ServerTransportStream
type ServiceConfig
type ServiceDesc
type ServiceInfo
type ServiceRegistrar
type SharedBufferPool
    func NewSharedBufferPool() SharedBufferPool
type StaticMethodCallOption
type Stream
type StreamClientInterceptor
type StreamDesc
type StreamHandler
type StreamServerInfo
type StreamServerInterceptor
type Streamer
type TrailerCallOption
type UnaryClientInterceptor
type UnaryHandler
type UnaryInvoker
type UnaryServerInfo
type UnaryServerInterceptor

Package files

backoff.go balancer_wrapper.go call.go clientconn.go codec.go dialoptions.go doc.go interceptor.go picker_wrapper.go pickfirst.go preloader.go resolver_wrapper.go rpc_util.go server.go service_config.go shared_buffer_pool.go stream.go stream_interfaces.go trace.go trace_withtrace.go version.go

Constants

The SupportPackageIsVersion variables are referenced from generated protocol buffer files to ensure compatibility with the gRPC version used. The latest support package version is 9.

Older versions are kept for compatibility.

These constants should not be referenced from any other code.

const (
    SupportPackageIsVersion3 = true
    SupportPackageIsVersion4 = true
    SupportPackageIsVersion5 = true
    SupportPackageIsVersion6 = true
    SupportPackageIsVersion7 = true
    SupportPackageIsVersion8 = true
    SupportPackageIsVersion9 = true
)
const (
    // PickFirstBalancerName is the name of the pick_first balancer.
    PickFirstBalancerName = "pick_first"
)

Version is the current grpc version.

const Version = "1.64.0"

Variables

DefaultBackoffConfig uses values specified for backoff in https://github.com/grpc/grpc/blob/master/doc/connection-backoff.md.

Deprecated: use ConnectParams instead. Will be supported throughout 1.x.

var DefaultBackoffConfig = BackoffConfig{
    MaxDelay: 120 * time.Second,
}

EnableTracing controls whether to trace RPCs using the golang.org/x/net/trace package. This should only be set before any RPCs are sent or received by this program.

var EnableTracing bool
var (
    // ErrClientConnClosing indicates that the operation is illegal because
    // the ClientConn is closing.
    //
    // Deprecated: this error should not be relied upon by users; use the status
    // code of Canceled instead.
    ErrClientConnClosing = status.Error(codes.Canceled, "grpc: the client connection is closing")
)

ErrClientConnTimeout indicates that the ClientConn cannot establish the underlying connections within the specified timeout.

Deprecated: This error is never returned by grpc and should not be referenced by users.

var ErrClientConnTimeout = errors.New("grpc: timed out when dialing")

ErrServerStopped indicates that the operation is now illegal because of the server being stopped.

var ErrServerStopped = errors.New("grpc: the server has been stopped")

func ClientSupportedCompressors

func ClientSupportedCompressors(ctx context.Context) ([]string, error)

ClientSupportedCompressors returns compressor names advertised by the client via grpc-accept-encoding header.

The context provided must be the context passed to the server's handler.

Experimental

Notice: This function is EXPERIMENTAL and may be changed or removed in a later release.

func Code

func Code(err error) codes.Code

Code returns the error code for err if it was produced by the rpc system. Otherwise, it returns codes.Unknown.

Deprecated: use status.Code instead.

func ErrorDesc

func ErrorDesc(err error) string

ErrorDesc returns the error description of err if it was produced by the rpc system. Otherwise, it returns err.Error() or empty string when err is nil.

Deprecated: use status.Convert and Message method instead.

func Errorf

func Errorf(c codes.Code, format string, a ...any) error

Errorf returns an error containing an error code and a description; Errorf returns nil if c is OK.

Deprecated: use status.Errorf instead.

func Invoke

func Invoke(ctx context.Context, method string, args, reply any, cc *ClientConn, opts ...CallOption) error

Invoke sends the RPC request on the wire and returns after response is received. This is typically called by generated code.

DEPRECATED: Use ClientConn.Invoke instead.

func Method

func Method(ctx context.Context) (string, bool)

Method returns the method string for the server context. The returned string is in the format of "/service/method".

func MethodFromServerStream

func MethodFromServerStream(stream ServerStream) (string, bool)

MethodFromServerStream returns the method string for the input stream. The returned string is in the format of "/service/method".

func NewContextWithServerTransportStream

func NewContextWithServerTransportStream(ctx context.Context, stream ServerTransportStream) context.Context

NewContextWithServerTransportStream creates a new context from ctx and attaches stream to it.

Experimental

Notice: This API is EXPERIMENTAL and may be changed or removed in a later release.

func SendHeader

func SendHeader(ctx context.Context, md metadata.MD) error

SendHeader sends header metadata. It may be called at most once, and may not be called after any event that causes headers to be sent (see SetHeader for a complete list). The provided md and headers set by SetHeader() will be sent.

The error returned is compatible with the status package. However, the status code will often not match the RPC status as seen by the client application, and therefore, should not be relied upon for this purpose.

func SetHeader

func SetHeader(ctx context.Context, md metadata.MD) error

SetHeader sets the header metadata to be sent from the server to the client. The context provided must be the context passed to the server's handler.

Streaming RPCs should prefer the SetHeader method of the ServerStream.

When called multiple times, all the provided metadata will be merged. All the metadata will be sent out when one of the following happens:

SetHeader will fail if called after any of the events above.

The error returned is compatible with the status package. However, the status code will often not match the RPC status as seen by the client application, and therefore, should not be relied upon for this purpose.

func SetSendCompressor

func SetSendCompressor(ctx context.Context, name string) error

SetSendCompressor sets a compressor for outbound messages from the server. It must not be called after any event that causes headers to be sent (see ServerStream.SetHeader for the complete list). Provided compressor is used when below conditions are met:

The context provided must be the context passed to the server's handler. It must be noted that compressor name encoding.Identity disables the outbound compression. By default, server messages will be sent using the same compressor with which request messages were sent.

It is not safe to call SetSendCompressor concurrently with SendHeader and SendMsg.

Experimental

Notice: This function is EXPERIMENTAL and may be changed or removed in a later release.

func SetTrailer

func SetTrailer(ctx context.Context, md metadata.MD) error

SetTrailer sets the trailer metadata that will be sent when an RPC returns. When called more than once, all the provided metadata will be merged.

The error returned is compatible with the status package. However, the status code will often not match the RPC status as seen by the client application, and therefore, should not be relied upon for this purpose.

type BackoffConfig

BackoffConfig defines the parameters for the default gRPC backoff strategy.

Deprecated: use ConnectParams instead. Will be supported throughout 1.x.

type BackoffConfig struct {
    // MaxDelay is the upper bound of backoff delay.
    MaxDelay time.Duration
}

type BidiStreamingClient

BidiStreamingClient represents the client side of a bidirectional-streaming (many requests, many responses) RPC. It is generic over both the type of the request message stream and the type of the response message stream. It is used in generated code.

type BidiStreamingClient[Req any, Res any] interface {
    Send(*Req) error
    Recv() (*Res, error)
    ClientStream
}

type BidiStreamingServer

BidiStreamingServer represents the server side of a bidirectional-streaming (many requests, many responses) RPC. It is generic over both the type of the request message stream and the type of the response message stream. It is used in generated code.

type BidiStreamingServer[Req any, Res any] interface {
    Recv() (*Req, error)
    Send(*Res) error
    ServerStream
}

type CallOption

CallOption configures a Call before it starts or extracts information from a Call after it completes.

type CallOption interface {
    // contains filtered or unexported methods
}

func CallContentSubtype

func CallContentSubtype(contentSubtype string) CallOption

CallContentSubtype returns a CallOption that will set the content-subtype for a call. For example, if content-subtype is "json", the Content-Type over the wire will be "application/grpc+json". The content-subtype is converted to lowercase before being included in Content-Type. See Content-Type on https://github.com/grpc/grpc/blob/master/doc/PROTOCOL-HTTP2.md#requests for more details.

If ForceCodec is not also used, the content-subtype will be used to look up the Codec to use in the registry controlled by RegisterCodec. See the documentation on RegisterCodec for details on registration. The lookup of content-subtype is case-insensitive. If no such Codec is found, the call will result in an error with code codes.Internal.

If ForceCodec is also used, that Codec will be used for all request and response messages, with the content-subtype set to the given contentSubtype here for requests.

func CallCustomCodec

func CallCustomCodec(codec Codec) CallOption

CallCustomCodec behaves like ForceCodec, but accepts a grpc.Codec instead of an encoding.Codec.

Deprecated: use ForceCodec instead.

func FailFast

func FailFast(failFast bool) CallOption

FailFast is the opposite of WaitForReady.

Deprecated: use WaitForReady.

func ForceCodec

func ForceCodec(codec encoding.Codec) CallOption

ForceCodec returns a CallOption that will set codec to be used for all request and response messages for a call. The result of calling Name() will be used as the content-subtype after converting to lowercase, unless CallContentSubtype is also used.

See Content-Type on https://github.com/grpc/grpc/blob/master/doc/PROTOCOL-HTTP2.md#requests for more details. Also see the documentation on RegisterCodec and CallContentSubtype for more details on the interaction between Codec and content-subtype.

This function is provided for advanced users; prefer to use only CallContentSubtype to select a registered codec instead.

Experimental

Notice: This API is EXPERIMENTAL and may be changed or removed in a later release.

func Header(md *metadata.MD) CallOption

Header returns a CallOptions that retrieves the header metadata for a unary RPC.

func MaxCallRecvMsgSize

func MaxCallRecvMsgSize(bytes int) CallOption

MaxCallRecvMsgSize returns a CallOption which sets the maximum message size in bytes the client can receive. If this is not set, gRPC uses the default 4MB.

func MaxCallSendMsgSize

func MaxCallSendMsgSize(bytes int) CallOption

MaxCallSendMsgSize returns a CallOption which sets the maximum message size in bytes the client can send. If this is not set, gRPC uses the default `math.MaxInt32`.

func MaxRetryRPCBufferSize

func MaxRetryRPCBufferSize(bytes int) CallOption

MaxRetryRPCBufferSize returns a CallOption that limits the amount of memory used for buffering this RPC's requests for retry purposes.

Experimental

Notice: This API is EXPERIMENTAL and may be changed or removed in a later release.

func OnFinish

func OnFinish(onFinish func(err error)) CallOption

OnFinish returns a CallOption that configures a callback to be called when the call completes. The error passed to the callback is the status of the RPC, and may be nil. The onFinish callback provided will only be called once by gRPC. This is mainly used to be used by streaming interceptors, to be notified when the RPC completes along with information about the status of the RPC.

Experimental

Notice: This API is EXPERIMENTAL and may be changed or removed in a later release.

func Peer

func Peer(p *peer.Peer) CallOption

Peer returns a CallOption that retrieves peer information for a unary RPC. The peer field will be populated *after* the RPC completes.

func PerRPCCredentials

func PerRPCCredentials(creds credentials.PerRPCCredentials) CallOption

PerRPCCredentials returns a CallOption that sets credentials.PerRPCCredentials for a call.

func StaticMethod

func StaticMethod() CallOption

StaticMethod returns a CallOption which specifies that a call is being made to a method that is static, which means the method is known at compile time and doesn't change at runtime. This can be used as a signal to stats plugins that this method is safe to include as a key to a measurement.

func Trailer

func Trailer(md *metadata.MD) CallOption

Trailer returns a CallOptions that retrieves the trailer metadata for a unary RPC.

func UseCompressor

func UseCompressor(name string) CallOption

UseCompressor returns a CallOption which sets the compressor used when sending the request. If WithCompressor is also set, UseCompressor has higher priority.

Experimental

Notice: This API is EXPERIMENTAL and may be changed or removed in a later release.

func WaitForReady

func WaitForReady(waitForReady bool) CallOption

WaitForReady configures the action to take when an RPC is attempted on broken connections or unreachable servers. If waitForReady is false and the connection is in the TRANSIENT_FAILURE state, the RPC will fail immediately. Otherwise, the RPC client will block the call until a connection is available (or the call is canceled or times out) and will retry the call if it fails due to a transient error. gRPC will not retry if data was written to the wire unless the server indicates it did not process the data. Please refer to https://github.com/grpc/grpc/blob/master/doc/wait-for-ready.md.

By default, RPCs don't "wait for ready".

type ClientConn

ClientConn represents a virtual connection to a conceptual endpoint, to perform RPCs.

A ClientConn is free to have zero or more actual connections to the endpoint based on configuration, load, etc. It is also free to determine which actual endpoints to use and may change it every RPC, permitting client-side load balancing.

A ClientConn encapsulates a range of functionality including name resolution, TCP connection establishment (with retries and backoff) and TLS handshakes. It also handles errors on established connections by re-resolving the name and reconnecting.

type ClientConn struct {
    // contains filtered or unexported fields
}

func Dial

func Dial(target string, opts ...DialOption) (*ClientConn, error)

Dial calls DialContext(context.Background(), target, opts...).

Deprecated: use NewClient instead. Will be supported throughout 1.x.

func DialContext

func DialContext(ctx context.Context, target string, opts ...DialOption) (conn *ClientConn, err error)

DialContext calls NewClient and then exits idle mode. If WithBlock(true) is used, it calls Connect and WaitForStateChange until either the context expires or the state of the ClientConn is Ready.

One subtle difference between NewClient and Dial and DialContext is that the former uses "dns" as the default name resolver, while the latter use "passthrough" for backward compatibility. This distinction should not matter to most users, but could matter to legacy users that specify a custom dialer and expect it to receive the target string directly.

Deprecated: use NewClient instead. Will be supported throughout 1.x.

func NewClient

func NewClient(target string, opts ...DialOption) (conn *ClientConn, err error)

NewClient creates a new gRPC "channel" for the target URI provided. No I/O is performed. Use of the ClientConn for RPCs will automatically cause it to connect. Connect may be used to manually create a connection, but for most users this is unnecessary.

The target name syntax is defined in https://github.com/grpc/grpc/blob/master/doc/naming.md. e.g. to use dns resolver, a "dns:///" prefix should be applied to the target.

The DialOptions returned by WithBlock, WithTimeout, WithReturnConnectionError, and FailOnNonTempDialError are ignored by this function.

func (*ClientConn) CanonicalTarget

func (cc *ClientConn) CanonicalTarget() string

CanonicalTarget returns the canonical target string of the ClientConn.

func (*ClientConn) Close

func (cc *ClientConn) Close() error

Close tears down the ClientConn and all underlying connections.

func (*ClientConn) Connect

func (cc *ClientConn) Connect()

Connect causes all subchannels in the ClientConn to attempt to connect if the channel is idle. Does not wait for the connection attempts to begin before returning.

Experimental

Notice: This API is EXPERIMENTAL and may be changed or removed in a later release.

func (*ClientConn) GetMethodConfig

func (cc *ClientConn) GetMethodConfig(method string) MethodConfig

GetMethodConfig gets the method config of the input method. If there's an exact match for input method (i.e. /service/method), we return the corresponding MethodConfig. If there isn't an exact match for the input method, we look for the service's default config under the service (i.e /service/) and then for the default for all services (empty string).

If there is a default MethodConfig for the service, we return it. Otherwise, we return an empty MethodConfig.

func (*ClientConn) GetState

func (cc *ClientConn) GetState() connectivity.State

GetState returns the connectivity.State of ClientConn.

Experimental

Notice: This API is EXPERIMENTAL and may be changed or removed in a later release.

func (*ClientConn) Invoke

func (cc *ClientConn) Invoke(ctx context.Context, method string, args, reply any, opts ...CallOption) error

Invoke sends the RPC request on the wire and returns after response is received. This is typically called by generated code.

All errors returned by Invoke are compatible with the status package.

func (*ClientConn) NewStream

func (cc *ClientConn) NewStream(ctx context.Context, desc *StreamDesc, method string, opts ...CallOption) (ClientStream, error)

NewStream creates a new Stream for the client side. This is typically called by generated code. ctx is used for the lifetime of the stream.

To ensure resources are not leaked due to the stream returned, one of the following actions must be performed:

  1. Call Close on the ClientConn.
  2. Cancel the context provided.
  3. Call RecvMsg until a non-nil error is returned. A protobuf-generated client-streaming RPC, for instance, might use the helper function CloseAndRecv (note that CloseSend does not Recv, therefore is not guaranteed to release all resources).
  4. Receive a non-nil, non-io.EOF error from Header or SendMsg.

If none of the above happen, a goroutine and a context will be leaked, and grpc will not call the optionally-configured stats handler with a stats.End message.

func (*ClientConn) ResetConnectBackoff

func (cc *ClientConn) ResetConnectBackoff()

ResetConnectBackoff wakes up all subchannels in transient failure and causes them to attempt another connection immediately. It also resets the backoff times used for subsequent attempts regardless of the current state.

In general, this function should not be used. Typical service or network outages result in a reasonable client reconnection strategy by default. However, if a previously unavailable network becomes available, this may be used to trigger an immediate reconnect.

Experimental

Notice: This API is EXPERIMENTAL and may be changed or removed in a later release.

func (*ClientConn) Target

func (cc *ClientConn) Target() string

Target returns the target string of the ClientConn.

func (*ClientConn) WaitForStateChange

func (cc *ClientConn) WaitForStateChange(ctx context.Context, sourceState connectivity.State) bool

WaitForStateChange waits until the connectivity.State of ClientConn changes from sourceState or ctx expires. A true value is returned in former case and false in latter.

Experimental

Notice: This API is EXPERIMENTAL and may be changed or removed in a later release.

type ClientConnInterface

ClientConnInterface defines the functions clients need to perform unary and streaming RPCs. It is implemented by *ClientConn, and is only intended to be referenced by generated code.

type ClientConnInterface interface {
    // Invoke performs a unary RPC and returns after the response is received
    // into reply.
    Invoke(ctx context.Context, method string, args any, reply any, opts ...CallOption) error
    // NewStream begins a streaming RPC.
    NewStream(ctx context.Context, desc *StreamDesc, method string, opts ...CallOption) (ClientStream, error)
}

type ClientStream

ClientStream defines the client-side behavior of a streaming RPC.

All errors returned from ClientStream methods are compatible with the status package.

type ClientStream interface {
    // Header returns the header metadata received from the server if there
    // is any. It blocks if the metadata is not ready to read.  If the metadata
    // is nil and the error is also nil, then the stream was terminated without
    // headers, and the status can be discovered by calling RecvMsg.
    Header() (metadata.MD, error)
    // Trailer returns the trailer metadata from the server, if there is any.
    // It must only be called after stream.CloseAndRecv has returned, or
    // stream.Recv has returned a non-nil error (including io.EOF).
    Trailer() metadata.MD
    // CloseSend closes the send direction of the stream. It closes the stream
    // when non-nil error is met. It is also not safe to call CloseSend
    // concurrently with SendMsg.
    CloseSend() error
    // Context returns the context for this stream.
    //
    // It should not be called until after Header or RecvMsg has returned. Once
    // called, subsequent client-side retries are disabled.
    Context() context.Context
    // SendMsg is generally called by generated code. On error, SendMsg aborts
    // the stream. If the error was generated by the client, the status is
    // returned directly; otherwise, io.EOF is returned and the status of
    // the stream may be discovered using RecvMsg.
    //
    // SendMsg blocks until:
    //   - There is sufficient flow control to schedule m with the transport, or
    //   - The stream is done, or
    //   - The stream breaks.
    //
    // SendMsg does not wait until the message is received by the server. An
    // untimely stream closure may result in lost messages. To ensure delivery,
    // users should ensure the RPC completed successfully using RecvMsg.
    //
    // It is safe to have a goroutine calling SendMsg and another goroutine
    // calling RecvMsg on the same stream at the same time, but it is not safe
    // to call SendMsg on the same stream in different goroutines. It is also
    // not safe to call CloseSend concurrently with SendMsg.
    //
    // It is not safe to modify the message after calling SendMsg. Tracing
    // libraries and stats handlers may use the message lazily.
    SendMsg(m any) error
    // RecvMsg blocks until it receives a message into m or the stream is
    // done. It returns io.EOF when the stream completes successfully. On
    // any other error, the stream is aborted and the error contains the RPC
    // status.
    //
    // It is safe to have a goroutine calling SendMsg and another goroutine
    // calling RecvMsg on the same stream at the same time, but it is not
    // safe to call RecvMsg on the same stream in different goroutines.
    RecvMsg(m any) error
}

func NewClientStream

func NewClientStream(ctx context.Context, desc *StreamDesc, cc *ClientConn, method string, opts ...CallOption) (ClientStream, error)

NewClientStream is a wrapper for ClientConn.NewStream.

type ClientStreamingClient

ClientStreamingClient represents the client side of a client-streaming (many requests, one response) RPC. It is generic over both the type of the request message stream and the type of the unary response message. It is used in generated code.

type ClientStreamingClient[Req any, Res any] interface {
    Send(*Req) error
    CloseAndRecv() (*Res, error)
    ClientStream
}

type ClientStreamingServer

ClientStreamingServer represents the server side of a client-streaming (many requests, one response) RPC. It is generic over both the type of the request message stream and the type of the unary response message. It is used in generated code.

type ClientStreamingServer[Req any, Res any] interface {
    Recv() (*Req, error)
    SendAndClose(*Res) error
    ServerStream
}

type Codec

Codec defines the interface gRPC uses to encode and decode messages. Note that implementations of this interface must be thread safe; a Codec's methods can be called from concurrent goroutines.

Deprecated: use encoding.Codec instead.

type Codec interface {
    // Marshal returns the wire format of v.
    Marshal(v any) ([]byte, error)
    // Unmarshal parses the wire format into v.
    Unmarshal(data []byte, v any) error
    // String returns the name of the Codec implementation.  This is unused by
    // gRPC.
    String() string
}

type Compressor

Compressor defines the interface gRPC uses to compress a message.

Deprecated: use package encoding.

type Compressor interface {
    // Do compresses p into w.
    Do(w io.Writer, p []byte) error
    // Type returns the compression algorithm the Compressor uses.
    Type() string
}

func NewGZIPCompressor

func NewGZIPCompressor() Compressor

NewGZIPCompressor creates a Compressor based on GZIP.

Deprecated: use package encoding/gzip.

func NewGZIPCompressorWithLevel

func NewGZIPCompressorWithLevel(level int) (Compressor, error)

NewGZIPCompressorWithLevel is like NewGZIPCompressor but specifies the gzip compression level instead of assuming DefaultCompression.

The error returned will be nil if the level is valid.

Deprecated: use package encoding/gzip.

type CompressorCallOption

CompressorCallOption is a CallOption that indicates the compressor to use.

Experimental

Notice: This type is EXPERIMENTAL and may be changed or removed in a later release.

type CompressorCallOption struct {
    CompressorType string
}

type ConnectParams

ConnectParams defines the parameters for connecting and retrying. Users are encouraged to use this instead of the BackoffConfig type defined above. See here for more details: https://github.com/grpc/grpc/blob/master/doc/connection-backoff.md.

Experimental

Notice: This type is EXPERIMENTAL and may be changed or removed in a later release.

type ConnectParams struct {
    // Backoff specifies the configuration options for connection backoff.
    Backoff backoff.Config
    // MinConnectTimeout is the minimum amount of time we are willing to give a
    // connection to complete.
    MinConnectTimeout time.Duration
}

type ContentSubtypeCallOption

ContentSubtypeCallOption is a CallOption that indicates the content-subtype used for marshaling messages.

Experimental

Notice: This type is EXPERIMENTAL and may be changed or removed in a later release.

type ContentSubtypeCallOption struct {
    ContentSubtype string
}

type CustomCodecCallOption

CustomCodecCallOption is a CallOption that indicates the codec used for marshaling messages.

Experimental

Notice: This type is EXPERIMENTAL and may be changed or removed in a later release.

type CustomCodecCallOption struct {
    Codec Codec
}

type Decompressor

Decompressor defines the interface gRPC uses to decompress a message.

Deprecated: use package encoding.

type Decompressor interface {
    // Do reads the data from r and uncompress them.
    Do(r io.Reader) ([]byte, error)
    // Type returns the compression algorithm the Decompressor uses.
    Type() string
}

func NewGZIPDecompressor

func NewGZIPDecompressor() Decompressor

NewGZIPDecompressor creates a Decompressor based on GZIP.

Deprecated: use package encoding/gzip.

type DialOption

DialOption configures how we set up the connection.

type DialOption interface {
    // contains filtered or unexported methods
}

func FailOnNonTempDialError

func FailOnNonTempDialError(f bool) DialOption

FailOnNonTempDialError returns a DialOption that specifies if gRPC fails on non-temporary dial errors. If f is true, and dialer returns a non-temporary error, gRPC will fail the connection to the network address and won't try to reconnect. The default value of FailOnNonTempDialError is false.

FailOnNonTempDialError only affects the initial dial, and does not do anything useful unless you are also using WithBlock().

Use of this feature is not recommended. For more information, please see: https://github.com/grpc/grpc-go/blob/master/Documentation/anti-patterns.md

Deprecated: this DialOption is not supported by NewClient. This API may be changed or removed in a later release.

func WithAuthority

func WithAuthority(a string) DialOption

WithAuthority returns a DialOption that specifies the value to be used as the :authority pseudo-header and as the server name in authentication handshake.

func WithBackoffConfig

func WithBackoffConfig(b BackoffConfig) DialOption

WithBackoffConfig configures the dialer to use the provided backoff parameters after connection failures.

Deprecated: use WithConnectParams instead. Will be supported throughout 1.x.

func WithBackoffMaxDelay

func WithBackoffMaxDelay(md time.Duration) DialOption

WithBackoffMaxDelay configures the dialer to use the provided maximum delay when backing off after failed connection attempts.

Deprecated: use WithConnectParams instead. Will be supported throughout 1.x.

func WithBlock

func WithBlock() DialOption

WithBlock returns a DialOption which makes callers of Dial block until the underlying connection is up. Without this, Dial returns immediately and connecting the server happens in background.

Use of this feature is not recommended. For more information, please see: https://github.com/grpc/grpc-go/blob/master/Documentation/anti-patterns.md

Deprecated: this DialOption is not supported by NewClient. Will be supported throughout 1.x.

func WithChainStreamInterceptor

func WithChainStreamInterceptor(interceptors ...StreamClientInterceptor) DialOption

WithChainStreamInterceptor returns a DialOption that specifies the chained interceptor for streaming RPCs. The first interceptor will be the outer most, while the last interceptor will be the inner most wrapper around the real call. All interceptors added by this method will be chained, and the interceptor defined by WithStreamInterceptor will always be prepended to the chain.

func WithChainUnaryInterceptor

func WithChainUnaryInterceptor(interceptors ...UnaryClientInterceptor) DialOption

WithChainUnaryInterceptor returns a DialOption that specifies the chained interceptor for unary RPCs. The first interceptor will be the outer most, while the last interceptor will be the inner most wrapper around the real call. All interceptors added by this method will be chained, and the interceptor defined by WithUnaryInterceptor will always be prepended to the chain.

func WithChannelzParentID

func WithChannelzParentID(c channelz.Identifier) DialOption

WithChannelzParentID returns a DialOption that specifies the channelz ID of current ClientConn's parent. This function is used in nested channel creation (e.g. grpclb dial).

Experimental

Notice: This API is EXPERIMENTAL and may be changed or removed in a later release.

func WithCodec

func WithCodec(c Codec) DialOption

WithCodec returns a DialOption which sets a codec for message marshaling and unmarshaling.

Deprecated: use WithDefaultCallOptions(ForceCodec(_)) instead. Will be supported throughout 1.x.

func WithCompressor

func WithCompressor(cp Compressor) DialOption

WithCompressor returns a DialOption which sets a Compressor to use for message compression. It has lower priority than the compressor set by the UseCompressor CallOption.

Deprecated: use UseCompressor instead. Will be supported throughout 1.x.

func WithConnectParams

func WithConnectParams(p ConnectParams) DialOption

WithConnectParams configures the ClientConn to use the provided ConnectParams for creating and maintaining connections to servers.

The backoff configuration specified as part of the ConnectParams overrides all defaults specified in https://github.com/grpc/grpc/blob/master/doc/connection-backoff.md. Consider using the backoff.DefaultConfig as a base, in cases where you want to override only a subset of the backoff configuration.

func WithContextDialer

func WithContextDialer(f func(context.Context, string) (net.Conn, error)) DialOption

WithContextDialer returns a DialOption that sets a dialer to create connections. If FailOnNonTempDialError() is set to true, and an error is returned by f, gRPC checks the error's Temporary() method to decide if it should try to reconnect to the network address.

Note: All supported releases of Go (as of December 2023) override the OS defaults for TCP keepalive time and interval to 15s. To enable TCP keepalive with OS defaults for keepalive time and interval, use a net.Dialer that sets the KeepAlive field to a negative value, and sets the SO_KEEPALIVE socket option to true from the Control field. For a concrete example of how to do this, see internal.NetDialerWithTCPKeepalive().

For more information, please see issue 23459 in the Go github repo.

func WithCredentialsBundle

func WithCredentialsBundle(b credentials.Bundle) DialOption

WithCredentialsBundle returns a DialOption to set a credentials bundle for the ClientConn.WithCreds. This should not be used together with WithTransportCredentials.

Experimental

Notice: This API is EXPERIMENTAL and may be changed or removed in a later release.

func WithDecompressor

func WithDecompressor(dc Decompressor) DialOption

WithDecompressor returns a DialOption which sets a Decompressor to use for incoming message decompression. If incoming response messages are encoded using the decompressor's Type(), it will be used. Otherwise, the message encoding will be used to look up the compressor registered via encoding.RegisterCompressor, which will then be used to decompress the message. If no compressor is registered for the encoding, an Unimplemented status error will be returned.

Deprecated: use encoding.RegisterCompressor instead. Will be supported throughout 1.x.

func WithDefaultCallOptions

func WithDefaultCallOptions(cos ...CallOption) DialOption

WithDefaultCallOptions returns a DialOption which sets the default CallOptions for calls over the connection.

func WithDefaultServiceConfig

func WithDefaultServiceConfig(s string) DialOption

WithDefaultServiceConfig returns a DialOption that configures the default service config, which will be used in cases where:

1. WithDisableServiceConfig is also used, or

2. The name resolver does not provide a service config or provides an invalid service config.

The parameter s is the JSON representation of the default service config. For more information about service configs, see: https://github.com/grpc/grpc/blob/master/doc/service_config.md For a simple example of usage, see: examples/features/load_balancing/client/main.go

func WithDialer

func WithDialer(f func(string, time.Duration) (net.Conn, error)) DialOption

WithDialer returns a DialOption that specifies a function to use for dialing network addresses. If FailOnNonTempDialError() is set to true, and an error is returned by f, gRPC checks the error's Temporary() method to decide if it should try to reconnect to the network address.

Deprecated: use WithContextDialer instead. Will be supported throughout 1.x.

func WithDisableHealthCheck

func WithDisableHealthCheck() DialOption

WithDisableHealthCheck disables the LB channel health checking for all SubConns of this ClientConn.

Experimental

Notice: This API is EXPERIMENTAL and may be changed or removed in a later release.

func WithDisableRetry

func WithDisableRetry() DialOption

WithDisableRetry returns a DialOption that disables retries, even if the service config enables them. This does not impact transparent retries, which will happen automatically if no data is written to the wire or if the RPC is unprocessed by the remote server.

func WithDisableServiceConfig

func WithDisableServiceConfig() DialOption

WithDisableServiceConfig returns a DialOption that causes gRPC to ignore any service config provided by the resolver and provides a hint to the resolver to not fetch service configs.

Note that this dial option only disables service config from resolver. If default service config is provided, gRPC will use the default service config.

func WithIdleTimeout

func WithIdleTimeout(d time.Duration) DialOption

WithIdleTimeout returns a DialOption that configures an idle timeout for the channel. If the channel is idle for the configured timeout, i.e there are no ongoing RPCs and no new RPCs are initiated, the channel will enter idle mode and as a result the name resolver and load balancer will be shut down. The channel will exit idle mode when the Connect() method is called or when an RPC is initiated.

A default timeout of 30 minutes will be used if this dial option is not set at dial time and idleness can be disabled by passing a timeout of zero.

Experimental

Notice: This API is EXPERIMENTAL and may be changed or removed in a later release.

func WithInitialConnWindowSize

func WithInitialConnWindowSize(s int32) DialOption

WithInitialConnWindowSize returns a DialOption which sets the value for initial window size on a connection. The lower bound for window size is 64K and any value smaller than that will be ignored.

func WithInitialWindowSize

func WithInitialWindowSize(s int32) DialOption

WithInitialWindowSize returns a DialOption which sets the value for initial window size on a stream. The lower bound for window size is 64K and any value smaller than that will be ignored.

func WithInsecure

func WithInsecure() DialOption

WithInsecure returns a DialOption which disables transport security for this ClientConn. Under the hood, it uses insecure.NewCredentials().

Note that using this DialOption with per-RPC credentials (through WithCredentialsBundle or WithPerRPCCredentials) which require transport security is incompatible and will cause grpc.Dial() to fail.

Deprecated: use WithTransportCredentials and insecure.NewCredentials() instead. Will be supported throughout 1.x.

func WithKeepaliveParams

func WithKeepaliveParams(kp keepalive.ClientParameters) DialOption

WithKeepaliveParams returns a DialOption that specifies keepalive parameters for the client transport.

func WithMaxHeaderListSize

func WithMaxHeaderListSize(s uint32) DialOption

WithMaxHeaderListSize returns a DialOption that specifies the maximum (uncompressed) size of header list that the client is prepared to accept.

func WithMaxMsgSize

func WithMaxMsgSize(s int) DialOption

WithMaxMsgSize returns a DialOption which sets the maximum message size the client can receive.

Deprecated: use WithDefaultCallOptions(MaxCallRecvMsgSize(s)) instead. Will be supported throughout 1.x.

func WithNoProxy

func WithNoProxy() DialOption

WithNoProxy returns a DialOption which disables the use of proxies for this ClientConn. This is ignored if WithDialer or WithContextDialer are used.

Experimental

Notice: This API is EXPERIMENTAL and may be changed or removed in a later release.

func WithPerRPCCredentials

func WithPerRPCCredentials(creds credentials.PerRPCCredentials) DialOption

WithPerRPCCredentials returns a DialOption which sets credentials and places auth state on each outbound RPC.

func WithReadBufferSize

func WithReadBufferSize(s int) DialOption

WithReadBufferSize lets you set the size of read buffer, this determines how much data can be read at most for each read syscall.

The default value for this buffer is 32KB. Zero or negative values will disable read buffer for a connection so data framer can access the underlying conn directly.

func WithRecvBufferPool

func WithRecvBufferPool(bufferPool SharedBufferPool) DialOption

WithRecvBufferPool returns a DialOption that configures the ClientConn to use the provided shared buffer pool for parsing incoming messages. Depending on the application's workload, this could result in reduced memory allocation.

If you are unsure about how to implement a memory pool but want to utilize one, begin with grpc.NewSharedBufferPool.

Note: The shared buffer pool feature will not be active if any of the following options are used: WithStatsHandler, EnableTracing, or binary logging. In such cases, the shared buffer pool will be ignored.

Deprecated: use experimental.WithRecvBufferPool instead. Will be deleted in v1.60.0 or later.

func WithResolvers

func WithResolvers(rs ...resolver.Builder) DialOption

WithResolvers allows a list of resolver implementations to be registered locally with the ClientConn without needing to be globally registered via resolver.Register. They will be matched against the scheme used for the current Dial only, and will take precedence over the global registry.

Experimental

Notice: This API is EXPERIMENTAL and may be changed or removed in a later release.

func WithReturnConnectionError

func WithReturnConnectionError() DialOption

WithReturnConnectionError returns a DialOption which makes the client connection return a string containing both the last connection error that occurred and the context.DeadlineExceeded error. Implies WithBlock()

Use of this feature is not recommended. For more information, please see: https://github.com/grpc/grpc-go/blob/master/Documentation/anti-patterns.md

Deprecated: this DialOption is not supported by NewClient. Will be supported throughout 1.x.

func WithSharedWriteBuffer

func WithSharedWriteBuffer(val bool) DialOption

WithSharedWriteBuffer allows reusing per-connection transport write buffer. If this option is set to true every connection will release the buffer after flushing the data on the wire.

Experimental

Notice: This API is EXPERIMENTAL and may be changed or removed in a later release.

func WithStatsHandler

func WithStatsHandler(h stats.Handler) DialOption

WithStatsHandler returns a DialOption that specifies the stats handler for all the RPCs and underlying network connections in this ClientConn.

func WithStreamInterceptor

func WithStreamInterceptor(f StreamClientInterceptor) DialOption

WithStreamInterceptor returns a DialOption that specifies the interceptor for streaming RPCs.

func WithTimeout

func WithTimeout(d time.Duration) DialOption

WithTimeout returns a DialOption that configures a timeout for dialing a ClientConn initially. This is valid if and only if WithBlock() is present.

Deprecated: this DialOption is not supported by NewClient. Will be supported throughout 1.x.

func WithTransportCredentials

func WithTransportCredentials(creds credentials.TransportCredentials) DialOption

WithTransportCredentials returns a DialOption which configures a connection level security credentials (e.g., TLS/SSL). This should not be used together with WithCredentialsBundle.

func WithUnaryInterceptor

func WithUnaryInterceptor(f UnaryClientInterceptor) DialOption

WithUnaryInterceptor returns a DialOption that specifies the interceptor for unary RPCs.

func WithUserAgent

func WithUserAgent(s string) DialOption

WithUserAgent returns a DialOption that specifies a user agent string for all the RPCs.

func WithWriteBufferSize

func WithWriteBufferSize(s int) DialOption

WithWriteBufferSize determines how much data can be batched before doing a write on the wire. The default value for this buffer is 32KB.

Zero or negative values will disable the write buffer such that each write will be on underlying connection. Note: A Send call may not directly translate to a write.

type EmptyCallOption

EmptyCallOption does not alter the Call configuration. It can be embedded in another structure to carry satellite data for use by interceptors.

type EmptyCallOption struct{}

type EmptyDialOption

EmptyDialOption does not alter the dial configuration. It can be embedded in another structure to build custom dial options.

Experimental

Notice: This type is EXPERIMENTAL and may be changed or removed in a later release.

type EmptyDialOption struct{}

type EmptyServerOption

EmptyServerOption does not alter the server configuration. It can be embedded in another structure to build custom server options.

Experimental

Notice: This type is EXPERIMENTAL and may be changed or removed in a later release.

type EmptyServerOption struct{}

type FailFastCallOption

FailFastCallOption is a CallOption for indicating whether an RPC should fail fast or not.

Experimental

Notice: This type is EXPERIMENTAL and may be changed or removed in a later release.

type FailFastCallOption struct {
    FailFast bool
}

type ForceCodecCallOption

ForceCodecCallOption is a CallOption that indicates the codec used for marshaling messages.

Experimental

Notice: This type is EXPERIMENTAL and may be changed or removed in a later release.

type ForceCodecCallOption struct {
    Codec encoding.Codec
}

type GenericClientStream

GenericClientStream implements the ServerStreamingClient, ClientStreamingClient, and BidiStreamingClient interfaces. It is used in generated code.

type GenericClientStream[Req any, Res any] struct {
    ClientStream
}

func (*GenericClientStream[Req, Res]) CloseAndRecv

func (x *GenericClientStream[Req, Res]) CloseAndRecv() (*Res, error)

CloseAndRecv closes the sending side of the stream, then receives the unary response from the server. The type of message which it returns is determined by the Res type parameter of the GenericClientStream receiver.

func (*GenericClientStream[Req, Res]) Recv

func (x *GenericClientStream[Req, Res]) Recv() (*Res, error)

Recv reads one message from the stream of responses generated by the server. The type of the message returned is determined by the Res type parameter of the GenericClientStream receiver.

func (*GenericClientStream[Req, Res]) Send

func (x *GenericClientStream[Req, Res]) Send(m *Req) error

Send pushes one message into the stream of requests to be consumed by the server. The type of message which can be sent is determined by the Req type parameter of the GenericClientStream receiver.

type GenericServerStream

GenericServerStream implements the ServerStreamingServer, ClientStreamingServer, and BidiStreamingServer interfaces. It is used in generated code.

type GenericServerStream[Req any, Res any] struct {
    ServerStream
}

func (*GenericServerStream[Req, Res]) Recv

func (x *GenericServerStream[Req, Res]) Recv() (*Req, error)

Recv reads one message from the stream of requests generated by the client. The type of the message returned is determined by the Req type parameter of the clientStreamServer receiver.

func (*GenericServerStream[Req, Res]) Send

func (x *GenericServerStream[Req, Res]) Send(m *Res) error

Send pushes one message into the stream of responses to be consumed by the client. The type of message which can be sent is determined by the Res type parameter of the serverStreamServer receiver.

func (*GenericServerStream[Req, Res]) SendAndClose

func (x *GenericServerStream[Req, Res]) SendAndClose(m *Res) error

SendAndClose pushes the unary response to the client. The type of message which can be sent is determined by the Res type parameter of the clientStreamServer receiver.

type HeaderCallOption

HeaderCallOption is a CallOption for collecting response header metadata. The metadata field will be populated *after* the RPC completes.

Experimental

Notice: This type is EXPERIMENTAL and may be changed or removed in a later release.

type HeaderCallOption struct {
    HeaderAddr *metadata.MD
}

type MaxHeaderListSizeDialOption

MaxHeaderListSizeDialOption is a DialOption that specifies the maximum (uncompressed) size of header list that the client is prepared to accept.

type MaxHeaderListSizeDialOption struct {
    MaxHeaderListSize uint32
}

type MaxHeaderListSizeServerOption

MaxHeaderListSizeServerOption is a ServerOption that sets the max (uncompressed) size of header list that the server is prepared to accept.

type MaxHeaderListSizeServerOption struct {
    MaxHeaderListSize uint32
}

type MaxRecvMsgSizeCallOption

MaxRecvMsgSizeCallOption is a CallOption that indicates the maximum message size in bytes the client can receive.

Experimental

Notice: This type is EXPERIMENTAL and may be changed or removed in a later release.

type MaxRecvMsgSizeCallOption struct {
    MaxRecvMsgSize int
}

type MaxRetryRPCBufferSizeCallOption

MaxRetryRPCBufferSizeCallOption is a CallOption indicating the amount of memory to be used for caching this RPC for retry purposes.

Experimental

Notice: This type is EXPERIMENTAL and may be changed or removed in a later release.

type MaxRetryRPCBufferSizeCallOption struct {
    MaxRetryRPCBufferSize int
}

type MaxSendMsgSizeCallOption

MaxSendMsgSizeCallOption is a CallOption that indicates the maximum message size in bytes the client can send.

Experimental

Notice: This type is EXPERIMENTAL and may be changed or removed in a later release.

type MaxSendMsgSizeCallOption struct {
    MaxSendMsgSize int
}

type MethodConfig

MethodConfig defines the configuration recommended by the service providers for a particular method.

Deprecated: Users should not use this struct. Service config should be received through name resolver, as specified here https://github.com/grpc/grpc/blob/master/doc/service_config.md

type MethodConfig = internalserviceconfig.MethodConfig

type MethodDesc

MethodDesc represents an RPC service's method specification.

type MethodDesc struct {
    MethodName string
    Handler    methodHandler
}

type MethodInfo

MethodInfo contains the information of an RPC including its method name and type.

type MethodInfo struct {
    // Name is the method name only, without the service name or package name.
    Name string
    // IsClientStream indicates whether the RPC is a client streaming RPC.
    IsClientStream bool
    // IsServerStream indicates whether the RPC is a server streaming RPC.
    IsServerStream bool
}

type OnFinishCallOption

OnFinishCallOption is CallOption that indicates a callback to be called when the call completes.

Experimental

Notice: This type is EXPERIMENTAL and may be changed or removed in a later release.

type OnFinishCallOption struct {
    OnFinish func(error)
}

type PeerCallOption

PeerCallOption is a CallOption for collecting the identity of the remote peer. The peer field will be populated *after* the RPC completes.

Experimental

Notice: This type is EXPERIMENTAL and may be changed or removed in a later release.

type PeerCallOption struct {
    PeerAddr *peer.Peer
}

type PerRPCCredsCallOption

PerRPCCredsCallOption is a CallOption that indicates the per-RPC credentials to use for the call.

Experimental

Notice: This type is EXPERIMENTAL and may be changed or removed in a later release.

type PerRPCCredsCallOption struct {
    Creds credentials.PerRPCCredentials
}

type PreparedMsg

PreparedMsg is responsible for creating a Marshalled and Compressed object.

Experimental

Notice: This type is EXPERIMENTAL and may be changed or removed in a later release.

type PreparedMsg struct {
    // contains filtered or unexported fields
}

func (*PreparedMsg) Encode

func (p *PreparedMsg) Encode(s Stream, msg any) error

Encode marshalls and compresses the message using the codec and compressor for the stream.

type Server

Server is a gRPC server to serve RPC requests.

type Server struct {
    // contains filtered or unexported fields
}

func NewServer

func NewServer(opt ...ServerOption) *Server

NewServer creates a gRPC server which has no service registered and has not started to accept requests yet.

func (*Server) GetServiceInfo

func (s *Server) GetServiceInfo() map[string]ServiceInfo

GetServiceInfo returns a map from service names to ServiceInfo. Service names include the package names, in the form of <package>.<service>.

func (*Server) GracefulStop

func (s *Server) GracefulStop()

GracefulStop stops the gRPC server gracefully. It stops the server from accepting new connections and RPCs and blocks until all the pending RPCs are finished.

func (*Server) RegisterService

func (s *Server) RegisterService(sd *ServiceDesc, ss any)

RegisterService registers a service and its implementation to the gRPC server. It is called from the IDL generated code. This must be called before invoking Serve. If ss is non-nil (for legacy code), its type is checked to ensure it implements sd.HandlerType.

func (*Server) Serve

func (s *Server) Serve(lis net.Listener) error

Serve accepts incoming connections on the listener lis, creating a new ServerTransport and service goroutine for each. The service goroutines read gRPC requests and then call the registered handlers to reply to them. Serve returns when lis.Accept fails with fatal errors. lis will be closed when this method returns. Serve will return a non-nil error unless Stop or GracefulStop is called.

Note: All supported releases of Go (as of December 2023) override the OS defaults for TCP keepalive time and interval to 15s. To enable TCP keepalive with OS defaults for keepalive time and interval, callers need to do the following two things:

func (*Server) ServeHTTP

func (s *Server) ServeHTTP(w http.ResponseWriter, r *http.Request)

ServeHTTP implements the Go standard library's http.Handler interface by responding to the gRPC request r, by looking up the requested gRPC method in the gRPC server s.

The provided HTTP request must have arrived on an HTTP/2 connection. When using the Go standard library's server, practically this means that the Request must also have arrived over TLS.

To share one port (such as 443 for https) between gRPC and an existing http.Handler, use a root http.Handler such as:

if r.ProtoMajor == 2 && strings.HasPrefix(
	r.Header.Get("Content-Type"), "application/grpc") {
	grpcServer.ServeHTTP(w, r)
} else {
	yourMux.ServeHTTP(w, r)
}

Note that ServeHTTP uses Go's HTTP/2 server implementation which is totally separate from grpc-go's HTTP/2 server. Performance and features may vary between the two paths. ServeHTTP does not support some gRPC features available through grpc-go's HTTP/2 server.

Experimental

Notice: This API is EXPERIMENTAL and may be changed or removed in a later release.

func (*Server) Stop

func (s *Server) Stop()

Stop stops the gRPC server. It immediately closes all open connections and listeners. It cancels all active RPCs on the server side and the corresponding pending RPCs on the client side will get notified by connection errors.

type ServerOption

A ServerOption sets options such as credentials, codec and keepalive parameters, etc.

type ServerOption interface {
    // contains filtered or unexported methods
}

func ChainStreamInterceptor

func ChainStreamInterceptor(interceptors ...StreamServerInterceptor) ServerOption

ChainStreamInterceptor returns a ServerOption that specifies the chained interceptor for streaming RPCs. The first interceptor will be the outer most, while the last interceptor will be the inner most wrapper around the real call. All stream interceptors added by this method will be chained.

func ChainUnaryInterceptor

func ChainUnaryInterceptor(interceptors ...UnaryServerInterceptor) ServerOption

ChainUnaryInterceptor returns a ServerOption that specifies the chained interceptor for unary RPCs. The first interceptor will be the outer most, while the last interceptor will be the inner most wrapper around the real call. All unary interceptors added by this method will be chained.

func ConnectionTimeout

func ConnectionTimeout(d time.Duration) ServerOption

ConnectionTimeout returns a ServerOption that sets the timeout for connection establishment (up to and including HTTP/2 handshaking) for all new connections. If this is not set, the default is 120 seconds. A zero or negative value will result in an immediate timeout.

Experimental

Notice: This API is EXPERIMENTAL and may be changed or removed in a later release.

func Creds

func Creds(c credentials.TransportCredentials) ServerOption

Creds returns a ServerOption that sets credentials for server connections.

func CustomCodec

func CustomCodec(codec Codec) ServerOption

CustomCodec returns a ServerOption that sets a codec for message marshaling and unmarshaling.

This will override any lookups by content-subtype for Codecs registered with RegisterCodec.

Deprecated: register codecs using encoding.RegisterCodec. The server will automatically use registered codecs based on the incoming requests' headers. See also https://github.com/grpc/grpc-go/blob/master/Documentation/encoding.md#using-a-codec. Will be supported throughout 1.x.

func ForceServerCodec

func ForceServerCodec(codec encoding.Codec) ServerOption

ForceServerCodec returns a ServerOption that sets a codec for message marshaling and unmarshaling.

This will override any lookups by content-subtype for Codecs registered with RegisterCodec.

See Content-Type on https://github.com/grpc/grpc/blob/master/doc/PROTOCOL-HTTP2.md#requests for more details. Also see the documentation on RegisterCodec and CallContentSubtype for more details on the interaction between encoding.Codec and content-subtype.

This function is provided for advanced users; prefer to register codecs using encoding.RegisterCodec. The server will automatically use registered codecs based on the incoming requests' headers. See also https://github.com/grpc/grpc-go/blob/master/Documentation/encoding.md#using-a-codec. Will be supported throughout 1.x.

Experimental

Notice: This API is EXPERIMENTAL and may be changed or removed in a later release.

func HeaderTableSize

func HeaderTableSize(s uint32) ServerOption

HeaderTableSize returns a ServerOption that sets the size of dynamic header table for stream.

Experimental

Notice: This API is EXPERIMENTAL and may be changed or removed in a later release.

func InTapHandle

func InTapHandle(h tap.ServerInHandle) ServerOption

InTapHandle returns a ServerOption that sets the tap handle for all the server transport to be created. Only one can be installed.

Experimental

Notice: This API is EXPERIMENTAL and may be changed or removed in a later release.

func InitialConnWindowSize

func InitialConnWindowSize(s int32) ServerOption

InitialConnWindowSize returns a ServerOption that sets window size for a connection. The lower bound for window size is 64K and any value smaller than that will be ignored.

func InitialWindowSize

func InitialWindowSize(s int32) ServerOption

InitialWindowSize returns a ServerOption that sets window size for stream. The lower bound for window size is 64K and any value smaller than that will be ignored.

func KeepaliveEnforcementPolicy

func KeepaliveEnforcementPolicy(kep keepalive.EnforcementPolicy) ServerOption

KeepaliveEnforcementPolicy returns a ServerOption that sets keepalive enforcement policy for the server.

func KeepaliveParams

func KeepaliveParams(kp keepalive.ServerParameters) ServerOption

KeepaliveParams returns a ServerOption that sets keepalive and max-age parameters for the server.

func MaxConcurrentStreams

func MaxConcurrentStreams(n uint32) ServerOption

MaxConcurrentStreams returns a ServerOption that will apply a limit on the number of concurrent streams to each ServerTransport.

func MaxHeaderListSize

func MaxHeaderListSize(s uint32) ServerOption

MaxHeaderListSize returns a ServerOption that sets the max (uncompressed) size of header list that the server is prepared to accept.

func MaxMsgSize

func MaxMsgSize(m int) ServerOption

MaxMsgSize returns a ServerOption to set the max message size in bytes the server can receive. If this is not set, gRPC uses the default limit.

Deprecated: use MaxRecvMsgSize instead. Will be supported throughout 1.x.

func MaxRecvMsgSize

func MaxRecvMsgSize(m int) ServerOption

MaxRecvMsgSize returns a ServerOption to set the max message size in bytes the server can receive. If this is not set, gRPC uses the default 4MB.

func MaxSendMsgSize

func MaxSendMsgSize(m int) ServerOption

MaxSendMsgSize returns a ServerOption to set the max message size in bytes the server can send. If this is not set, gRPC uses the default `math.MaxInt32`.

func NumStreamWorkers

func NumStreamWorkers(numServerWorkers uint32) ServerOption

NumStreamWorkers returns a ServerOption that sets the number of worker goroutines that should be used to process incoming streams. Setting this to zero (default) will disable workers and spawn a new goroutine for each stream.

Experimental

Notice: This API is EXPERIMENTAL and may be changed or removed in a later release.

func RPCCompressor

func RPCCompressor(cp Compressor) ServerOption

RPCCompressor returns a ServerOption that sets a compressor for outbound messages. For backward compatibility, all outbound messages will be sent using this compressor, regardless of incoming message compression. By default, server messages will be sent using the same compressor with which request messages were sent.

Deprecated: use encoding.RegisterCompressor instead. Will be supported throughout 1.x.

func RPCDecompressor

func RPCDecompressor(dc Decompressor) ServerOption

RPCDecompressor returns a ServerOption that sets a decompressor for inbound messages. It has higher priority than decompressors registered via encoding.RegisterCompressor.

Deprecated: use encoding.RegisterCompressor instead. Will be supported throughout 1.x.

func ReadBufferSize

func ReadBufferSize(s int) ServerOption

ReadBufferSize lets you set the size of read buffer, this determines how much data can be read at most for one read syscall. The default value for this buffer is 32KB. Zero or negative values will disable read buffer for a connection so data framer can access the underlying conn directly.

func RecvBufferPool

func RecvBufferPool(bufferPool SharedBufferPool) ServerOption

RecvBufferPool returns a ServerOption that configures the server to use the provided shared buffer pool for parsing incoming messages. Depending on the application's workload, this could result in reduced memory allocation.

If you are unsure about how to implement a memory pool but want to utilize one, begin with grpc.NewSharedBufferPool.

Note: The shared buffer pool feature will not be active if any of the following options are used: StatsHandler, EnableTracing, or binary logging. In such cases, the shared buffer pool will be ignored.

Deprecated: use experimental.WithRecvBufferPool instead. Will be deleted in v1.60.0 or later.

func SharedWriteBuffer

func SharedWriteBuffer(val bool) ServerOption

SharedWriteBuffer allows reusing per-connection transport write buffer. If this option is set to true every connection will release the buffer after flushing the data on the wire.

Experimental

Notice: This API is EXPERIMENTAL and may be changed or removed in a later release.

func StatsHandler

func StatsHandler(h stats.Handler) ServerOption

StatsHandler returns a ServerOption that sets the stats handler for the server.

func StreamInterceptor

func StreamInterceptor(i StreamServerInterceptor) ServerOption

StreamInterceptor returns a ServerOption that sets the StreamServerInterceptor for the server. Only one stream interceptor can be installed.

func UnaryInterceptor

func UnaryInterceptor(i UnaryServerInterceptor) ServerOption

UnaryInterceptor returns a ServerOption that sets the UnaryServerInterceptor for the server. Only one unary interceptor can be installed. The construction of multiple interceptors (e.g., chaining) can be implemented at the caller.

func UnknownServiceHandler

func UnknownServiceHandler(streamHandler StreamHandler) ServerOption

UnknownServiceHandler returns a ServerOption that allows for adding a custom unknown service handler. The provided method is a bidi-streaming RPC service handler that will be invoked instead of returning the "unimplemented" gRPC error whenever a request is received for an unregistered service or method. The handling function and stream interceptor (if set) have full access to the ServerStream, including its Context.

func WaitForHandlers

func WaitForHandlers(w bool) ServerOption

WaitForHandlers cause Stop to wait until all outstanding method handlers have exited before returning. If false, Stop will return as soon as all connections have closed, but method handlers may still be running. By default, Stop does not wait for method handlers to return.

Experimental

Notice: This API is EXPERIMENTAL and may be changed or removed in a later release.

func WriteBufferSize

func WriteBufferSize(s int) ServerOption

WriteBufferSize determines how much data can be batched before doing a write on the wire. The default value for this buffer is 32KB. Zero or negative values will disable the write buffer such that each write will be on underlying connection. Note: A Send call may not directly translate to a write.

type ServerStream

ServerStream defines the server-side behavior of a streaming RPC.

Errors returned from ServerStream methods are compatible with the status package. However, the status code will often not match the RPC status as seen by the client application, and therefore, should not be relied upon for this purpose.

type ServerStream interface {
    // SetHeader sets the header metadata. It may be called multiple times.
    // When call multiple times, all the provided metadata will be merged.
    // All the metadata will be sent out when one of the following happens:
    //  - ServerStream.SendHeader() is called;
    //  - The first response is sent out;
    //  - An RPC status is sent out (error or success).
    SetHeader(metadata.MD) error
    // SendHeader sends the header metadata.
    // The provided md and headers set by SetHeader() will be sent.
    // It fails if called multiple times.
    SendHeader(metadata.MD) error
    // SetTrailer sets the trailer metadata which will be sent with the RPC status.
    // When called more than once, all the provided metadata will be merged.
    SetTrailer(metadata.MD)
    // Context returns the context for this stream.
    Context() context.Context
    // SendMsg sends a message. On error, SendMsg aborts the stream and the
    // error is returned directly.
    //
    // SendMsg blocks until:
    //   - There is sufficient flow control to schedule m with the transport, or
    //   - The stream is done, or
    //   - The stream breaks.
    //
    // SendMsg does not wait until the message is received by the client. An
    // untimely stream closure may result in lost messages.
    //
    // It is safe to have a goroutine calling SendMsg and another goroutine
    // calling RecvMsg on the same stream at the same time, but it is not safe
    // to call SendMsg on the same stream in different goroutines.
    //
    // It is not safe to modify the message after calling SendMsg. Tracing
    // libraries and stats handlers may use the message lazily.
    SendMsg(m any) error
    // RecvMsg blocks until it receives a message into m or the stream is
    // done. It returns io.EOF when the client has performed a CloseSend. On
    // any non-EOF error, the stream is aborted and the error contains the
    // RPC status.
    //
    // It is safe to have a goroutine calling SendMsg and another goroutine
    // calling RecvMsg on the same stream at the same time, but it is not
    // safe to call RecvMsg on the same stream in different goroutines.
    RecvMsg(m any) error
}

type ServerStreamingClient

ServerStreamingClient represents the client side of a server-streaming (one request, many responses) RPC. It is generic over the type of the response message. It is used in generated code.

type ServerStreamingClient[Res any] interface {
    Recv() (*Res, error)
    ClientStream
}

type ServerStreamingServer

ServerStreamingServer represents the server side of a server-streaming (one request, many responses) RPC. It is generic over the type of the response message. It is used in generated code.

type ServerStreamingServer[Res any] interface {
    Send(*Res) error
    ServerStream
}

type ServerTransportStream

ServerTransportStream is a minimal interface that a transport stream must implement. This can be used to mock an actual transport stream for tests of handler code that use, for example, grpc.SetHeader (which requires some stream to be in context).

See also NewContextWithServerTransportStream.

Experimental

Notice: This type is EXPERIMENTAL and may be changed or removed in a later release.

type ServerTransportStream interface {
    Method() string
    SetHeader(md metadata.MD) error
    SendHeader(md metadata.MD) error
    SetTrailer(md metadata.MD) error
}

func ServerTransportStreamFromContext

func ServerTransportStreamFromContext(ctx context.Context) ServerTransportStream

ServerTransportStreamFromContext returns the ServerTransportStream saved in ctx. Returns nil if the given context has no stream associated with it (which implies it is not an RPC invocation context).

Experimental

Notice: This API is EXPERIMENTAL and may be changed or removed in a later release.

type ServiceConfig

ServiceConfig is provided by the service provider and contains parameters for how clients that connect to the service should behave.

Deprecated: Users should not use this struct. Service config should be received through name resolver, as specified here https://github.com/grpc/grpc/blob/master/doc/service_config.md

type ServiceConfig struct {
    serviceconfig.Config

    // Methods contains a map for the methods in this service.  If there is an
    // exact match for a method (i.e. /service/method) in the map, use the
    // corresponding MethodConfig.  If there's no exact match, look for the
    // default config for the service (/service/) and use the corresponding
    // MethodConfig if it exists.  Otherwise, the method has no MethodConfig to
    // use.
    Methods map[string]MethodConfig
    // contains filtered or unexported fields
}

type ServiceDesc

ServiceDesc represents an RPC service's specification.

type ServiceDesc struct {
    ServiceName string
    // The pointer to the service interface. Used to check whether the user
    // provided implementation satisfies the interface requirements.
    HandlerType any
    Methods     []MethodDesc
    Streams     []StreamDesc
    Metadata    any
}

type ServiceInfo

ServiceInfo contains unary RPC method info, streaming RPC method info and metadata for a service.

type ServiceInfo struct {
    Methods []MethodInfo
    // Metadata is the metadata specified in ServiceDesc when registering service.
    Metadata any
}

type ServiceRegistrar

ServiceRegistrar wraps a single method that supports service registration. It enables users to pass concrete types other than grpc.Server to the service registration methods exported by the IDL generated code.

type ServiceRegistrar interface {
    // RegisterService registers a service and its implementation to the
    // concrete type implementing this interface.  It may not be called
    // once the server has started serving.
    // desc describes the service and its methods and handlers. impl is the
    // service implementation which is passed to the method handlers.
    RegisterService(desc *ServiceDesc, impl any)
}

type SharedBufferPool

SharedBufferPool is a pool of buffers that can be shared, resulting in decreased memory allocation. Currently, in gRPC-go, it is only utilized for parsing incoming messages.

Experimental

Notice: This API is EXPERIMENTAL and may be changed or removed in a later release.

type SharedBufferPool interface {
    // Get returns a buffer with specified length from the pool.
    //
    // The returned byte slice may be not zero initialized.
    Get(length int) []byte

    // Put returns a buffer to the pool.
    Put(*[]byte)
}

func NewSharedBufferPool

func NewSharedBufferPool() SharedBufferPool

NewSharedBufferPool creates a simple SharedBufferPool with buckets of different sizes to optimize memory usage. This prevents the pool from wasting large amounts of memory, even when handling messages of varying sizes.

Experimental

Notice: This API is EXPERIMENTAL and may be changed or removed in a later release.

type StaticMethodCallOption

StaticMethodCallOption is a CallOption that specifies that a call comes from a static method.

type StaticMethodCallOption struct {
    EmptyCallOption
}

type Stream

Stream defines the common interface a client or server stream has to satisfy.

Deprecated: See ClientStream and ServerStream documentation instead.

type Stream interface {
    // Deprecated: See ClientStream and ServerStream documentation instead.
    Context() context.Context
    // Deprecated: See ClientStream and ServerStream documentation instead.
    SendMsg(m any) error
    // Deprecated: See ClientStream and ServerStream documentation instead.
    RecvMsg(m any) error
}

type StreamClientInterceptor

StreamClientInterceptor intercepts the creation of a ClientStream. Stream interceptors can be specified as a DialOption, using WithStreamInterceptor() or WithChainStreamInterceptor(), when creating a ClientConn. When a stream interceptor(s) is set on the ClientConn, gRPC delegates all stream creations to the interceptor, and it is the responsibility of the interceptor to call streamer.

desc contains a description of the stream. cc is the ClientConn on which the RPC was invoked. streamer is the handler to create a ClientStream and it is the responsibility of the interceptor to call it. opts contain all applicable call options, including defaults from the ClientConn as well as per-call options.

StreamClientInterceptor may return a custom ClientStream to intercept all I/O operations. The returned error must be compatible with the status package.

type StreamClientInterceptor func(ctx context.Context, desc *StreamDesc, cc *ClientConn, method string, streamer Streamer, opts ...CallOption) (ClientStream, error)

type StreamDesc

StreamDesc represents a streaming RPC service's method specification. Used on the server when registering services and on the client when initiating new streams.

type StreamDesc struct {
    // StreamName and Handler are only used when registering handlers on a
    // server.
    StreamName string        // the name of the method excluding the service
    Handler    StreamHandler // the handler called for the method

    // ServerStreams and ClientStreams are used for registering handlers on a
    // server as well as defining RPC behavior when passed to NewClientStream
    // and ClientConn.NewStream.  At least one must be true.
    ServerStreams bool // indicates the server can perform streaming sends
    ClientStreams bool // indicates the client can perform streaming sends
}

type StreamHandler

StreamHandler defines the handler called by gRPC server to complete the execution of a streaming RPC.

If a StreamHandler returns an error, it should either be produced by the status package, or be one of the context errors. Otherwise, gRPC will use codes.Unknown as the status code and err.Error() as the status message of the RPC.

type StreamHandler func(srv any, stream ServerStream) error

type StreamServerInfo

StreamServerInfo consists of various information about a streaming RPC on server side. All per-rpc information may be mutated by the interceptor.

type StreamServerInfo struct {
    // FullMethod is the full RPC method string, i.e., /package.service/method.
    FullMethod string
    // IsClientStream indicates whether the RPC is a client streaming RPC.
    IsClientStream bool
    // IsServerStream indicates whether the RPC is a server streaming RPC.
    IsServerStream bool
}

type StreamServerInterceptor

StreamServerInterceptor provides a hook to intercept the execution of a streaming RPC on the server. info contains all the information of this RPC the interceptor can operate on. And handler is the service method implementation. It is the responsibility of the interceptor to invoke handler to complete the RPC.

type StreamServerInterceptor func(srv any, ss ServerStream, info *StreamServerInfo, handler StreamHandler) error

type Streamer

Streamer is called by StreamClientInterceptor to create a ClientStream.

type Streamer func(ctx context.Context, desc *StreamDesc, cc *ClientConn, method string, opts ...CallOption) (ClientStream, error)

type TrailerCallOption

TrailerCallOption is a CallOption for collecting response trailer metadata. The metadata field will be populated *after* the RPC completes.

Experimental

Notice: This type is EXPERIMENTAL and may be changed or removed in a later release.

type TrailerCallOption struct {
    TrailerAddr *metadata.MD
}

type UnaryClientInterceptor

UnaryClientInterceptor intercepts the execution of a unary RPC on the client. Unary interceptors can be specified as a DialOption, using WithUnaryInterceptor() or WithChainUnaryInterceptor(), when creating a ClientConn. When a unary interceptor(s) is set on a ClientConn, gRPC delegates all unary RPC invocations to the interceptor, and it is the responsibility of the interceptor to call invoker to complete the processing of the RPC.

method is the RPC name. req and reply are the corresponding request and response messages. cc is the ClientConn on which the RPC was invoked. invoker is the handler to complete the RPC and it is the responsibility of the interceptor to call it. opts contain all applicable call options, including defaults from the ClientConn as well as per-call options.

The returned error must be compatible with the status package.

type UnaryClientInterceptor func(ctx context.Context, method string, req, reply any, cc *ClientConn, invoker UnaryInvoker, opts ...CallOption) error

type UnaryHandler

UnaryHandler defines the handler invoked by UnaryServerInterceptor to complete the normal execution of a unary RPC.

If a UnaryHandler returns an error, it should either be produced by the status package, or be one of the context errors. Otherwise, gRPC will use codes.Unknown as the status code and err.Error() as the status message of the RPC.

type UnaryHandler func(ctx context.Context, req any) (any, error)

type UnaryInvoker

UnaryInvoker is called by UnaryClientInterceptor to complete RPCs.

type UnaryInvoker func(ctx context.Context, method string, req, reply any, cc *ClientConn, opts ...CallOption) error

type UnaryServerInfo

UnaryServerInfo consists of various information about a unary RPC on server side. All per-rpc information may be mutated by the interceptor.

type UnaryServerInfo struct {
    // Server is the service implementation the user provides. This is read-only.
    Server any
    // FullMethod is the full RPC method string, i.e., /package.service/method.
    FullMethod string
}

type UnaryServerInterceptor

UnaryServerInterceptor provides a hook to intercept the execution of a unary RPC on the server. info contains all the information of this RPC the interceptor can operate on. And handler is the wrapper of the service method implementation. It is the responsibility of the interceptor to invoke handler to complete the RPC.

type UnaryServerInterceptor func(ctx context.Context, req any, info *UnaryServerInfo, handler UnaryHandler) (resp any, err error)

Subdirectories

Name Synopsis
..
admin Package admin provides a convenient method for registering a collection of administration services to a gRPC server.
test Package test contains test only functions for package admin.
attributes Package attributes defines a generic key/value store used in various gRPC components.
authz Package authz exposes methods to manage authorization within gRPC.
audit Package audit contains interfaces for audit logging during authorization.
stdout Package stdout defines an stdout audit logger.
backoff Package backoff provides configuration options for backoff.
balancer Package balancer defines APIs for load balancing in gRPC.
base Package base defines a balancer base that can be used to build balancers with different picking algorithms.
endpointsharding Package endpointsharding implements a load balancing policy that manages homogeneous child policies each owning a single endpoint.
grpclb Package grpclb defines a grpclb balancer.
grpc_lb_v1
state Package state declares grpclb types to be set by resolvers wishing to pass information to grpclb via resolver.State Attributes.
leastrequest Package leastrequest implements a least request load balancer.
rls Package rls implements the RLS LB policy.
roundrobin Package roundrobin defines a roundrobin balancer.
weightedroundrobin Package weightedroundrobin provides an implementation of the weighted round robin LB policy, as defined in [gRFC A58].
weightedtarget Package weightedtarget implements the weighted_target balancer.
weightedaggregator Package weightedaggregator implements state aggregator for weighted_target balancer.
benchmark Package benchmark implements the building blocks to setup end-to-end gRPC benchmarks.
benchmain Package main provides benchmark with setting flags.
benchresult To format the benchmark result:
client Package main provides a client used for benchmarking.
flags Package flags provide convenience types and routines to accept specific types of flag values on the command line.
latency Package latency provides wrappers for net.Conn, net.Listener, and net.Dialers, designed to interoperate to inject real-world latency into network connections.
server Package main provides a server used for benchmarking.
stats Package stats tracks the statistics associated with benchmark runs.
worker Binary worker implements the benchmark worker that can turn into a benchmark client or server.
binarylog Package binarylog implementation binary logging as defined in https://github.com/grpc/proposal/blob/master/A16-binary-logging.md.
grpc_binarylog_v1
channelz Package channelz exports internals of the channelz implementation as required by other gRPC packages.
grpc_channelz_v1
service Package service provides an implementation for channelz service server.
codes Package codes defines the canonical error codes used by gRPC.
connectivity Package connectivity defines connectivity semantics.
credentials Package credentials implements various credentials supported by gRPC library, which encapsulate all the state needed by a client to authenticate with a server and make various assertions, e.g., about the client's identity, role, or whether it is authorized to make a particular call.
alts Package alts implements the ALTS credential support by gRPC library, which encapsulates all the state needed by a client to authenticate with a server using ALTS and make various assertions, e.g., about the client's identity, role, or whether it is authorized to make a particular call.
google Package google defines credentials for google cloud services.
insecure Package insecure provides an implementation of the credentials.TransportCredentials interface which disables transport security.
local Package local implements local transport credentials.
oauth Package oauth implements gRPC credentials using OAuth.
sts Package sts implements call credentials using STS (Security Token Service) as defined in https://tools.ietf.org/html/rfc8693.
tls
certprovider Package certprovider defines APIs for Certificate Providers in gRPC.
pemfile Package pemfile provides a file watching certificate provider plugin implementation which works for files with PEM contents.
xds Package xds provides a transport credentials implementation where the security configuration is pushed by a management server using xDS APIs.
encoding Package encoding defines the interface for the compressor and codec, and functions to register and retrieve compressors and codecs.
gzip Package gzip implements and registers the gzip compressor during the initialization.
proto Package proto defines the protobuf codec.
experimental Package experimental is a collection of experimental features that might have some rough edges to them.
grpclog Package grpclog defines logging for grpc.
glogger Package glogger defines glog-based logging for grpc.
health Package health provides a service that exposes server's health and it must be imported to enable support for client-side health checks.
grpc_health_v1
interop Package interop contains functions used by interop client/server.
alts
client This binary can only run on Google Cloud Platform (GCP).
server This binary can only run on Google Cloud Platform (GCP).
client Binary client is an interop client.
fake_grpclb This file is for testing only.
grpc_testing
core
grpclb_fallback Binary grpclb_fallback is an interop test client for grpclb fallback.
http2 Binary http2 is used to test http2 error edge cases like GOAWAYs and RST_STREAMs
server Binary server is an interop server.
stress
client client starts an interop client to do stress test and a metrics server to report qps.
grpc_testing
metrics_client Binary metrics_client is a client to retrieve metrics from the server.
xds Package xds contains various xds interop helpers for usage in interop tests.
client Binary client for xDS interop tests.
server Binary server is the server used for xDS interop tests.
xds_federation Binary client is an interop client.
keepalive Package keepalive defines configurable parameters for point-to-point healthcheck.
metadata Package metadata define the structure of the metadata supported by gRPC library.
orca Package orca implements Open Request Cost Aggregation, which is an open standard for request cost aggregation and reporting by backends and the corresponding aggregation of such reports by L7 load balancers (such as Envoy) on the data plane.
peer Package peer defines various peer information associated with RPCs and corresponding utils.
profiling Package profiling exposes methods to manage profiling within gRPC.
cmd Binary cmd is a command-line tool for profiling management.
proto
service Package service defines methods to register a gRPC client/service for a profiling service that is exposed in the same server.
reflection Package reflection implements server reflection service.
grpc_reflection_v1
grpc_reflection_v1alpha
grpc_testing
resolver Package resolver defines APIs for name resolution in gRPC.
dns Package dns implements a dns resolver to be installed as the default resolver in grpc.
manual Package manual defines a resolver that can be used to manually send resolved addresses to ClientConn.
passthrough Package passthrough implements a pass-through resolver.
serviceconfig Package serviceconfig defines types and methods for operating on gRPC service configs.
stats Package stats is for collecting and reporting various network and RPC stats.
status Package status implements errors returned by gRPC.
tap Package tap defines the function handles which are executed on the transport layer of gRPC-Go and related information.
test Package test contains tests.
bufconn Package bufconn provides a net.Conn implemented by a buffer and related dialing and listening functionality.
codec_perf
xds Package xds contains an implementation of the xDS suite of protocols, to be used by gRPC client and server applications.
bootstrap Package bootstrap provides the functionality to register possible options for aspects of the xDS client through the bootstrap file.
csds Package csds implements features to dump the status (xDS responses) the xds_client is using.
googledirectpath Package googledirectpath implements a resolver that configures xds to make cloud to prod directpath connection.