All Classes and Interfaces
Class
Description
Stub implementations for async stubs.
Stub implementations for blocking stubs.
The abstract base class for
ClientStream
implementations.A sink for outbound operations, separated from the stream simply to avoid name
collisions/confusion.
This should only be called from the transport thread.
Stub implementations for future stubs.
Base class for all Netty gRPC handlers.
Controls whether PINGs like those for BDP are permitted to be sent at the current time.
Abstract base class for
ReadableBuffer
implementations.Abstract base class for
ServerStream
implementations.A sink for outbound operations, separated from the stream simply to avoid name
collisions/confusion.
This should only be called from the transport thread (except for private interactions with
AbstractServerStream
).The stream and stream state as used by the application.
Stream state as used by the transport.
Common base type for stub implementations.
A factory class for stub.
The base interface of the Subchannels returned by
LoadBalancer.Helper.createSubchannel(io.grpc.LoadBalancer.CreateSubchannelArgs)
.Implementation of
Throttler
that keeps track of recent history (the duration of which is
specified to the constructor) and throttles requests at the client side based on the number of
requests that the
backend has accepted and the total number of requests generated.Builder for
AdaptiveThrottler
.Holds the data for each slot (amount and end timestamp).
Address information
Address represents the address used to create the socket.
Address information
Address represents the address used to create the socket.
An address type not included above.
An address type not included above.
Protobuf type
grpc.channelz.v1.Address.TcpIpAddress
Protobuf type
grpc.channelz.v1.Address.TcpIpAddress
Protobuf enum
grpc.binarylog.v1.Address.Type
A Unix Domain Socket address.
A Unix Domain Socket address.
Admin Interface provides a class of services for exposing the overall state of gRPC
activity in a given binary.
AdvancedTlsX509KeyManager is an
X509ExtendedKeyManager
that allows users to configure
advanced TLS features, such as private key and certificate chain reloading.Mainly used to avoid throwing IO Exceptions in java.io.Closeable.
AdvancedTlsX509TrustManager is an
X509ExtendedTrustManager
that allows users to configure
advanced TLS features, such as root certificate reloading and peer cert custom verification.Builds a new
AdvancedTlsX509TrustManager
.The verification mode when authenticating the peer certificate.
Custom SocketAddress class for
InProcessTransport
, for
a server which can only be referenced via this address instance.Sits between
AbstractStream.TransportState
and MessageDeframer
to deframe in the
client thread.Listener for when deframing on the application thread, which calls the real listener on the
transport thread.
Handles write actions from the container thread and the application thread.
Handles write actions from the container thread and the application thread.
Write actions, e.g.
Write actions, e.g.
A
long
atomically updated due to errors caused by the value being too small.An implementation of
LongCounter
that is just an AtomicLong
.An immutable type-safe container of attributes.
The helper class to build an Attributes instance.
Key for an key-value pair.
Determines how long to wait before doing some action (typically a retry, or a reconnect).
Schedules a retry operation according to a
BackoffPolicy
.A binary log that can be installed on a channel or server.
The default implementation of a
BinaryLogProvider
.A class that accepts binary log messages.
Provides a way to bind instance of service implementation to server.
A binary log class that is configured for a specific
MethodDescriptor
.A
SubchannelPool
that keeps returned LoadBalancer.Subchannel
s for a given time before it's
shut down by the pool.A CachingRlsLbClient is a core implementation of RLS loadbalancer supports dynamic request
routing by fetching the decision from route lookup server.
When any
CachingRlsLbClient.CacheEntry
is evicted from LruCache
, it performs CachingRlsLbClient.CacheEntry.cleanup()
after original LruCache.EvictionListener
is finished.Implementation of
CachingRlsLbClient.CacheEntry
contains error.A Builder for
CachingRlsLbClient
.Viewer class for cached
RlsProtoData.RouteLookupResponse
and associated LbPolicyConfiguration.ChildPolicyWrapper
.Common cache entry data for
CachingRlsLbClient.RlsAsyncLruCache
.A Throttler never throttles.
A pending cache entry when the async RouteLookup RPC is still on the fly.
Implementation of
LinkedHashLruCache
for RLS.Tagging interface for MetricInstruments that can be used with batch callbacks.
Carries credential data that will be propagated to the server via request metadata for each RPC.
The outlet of the produced headers.
The request-related information passed to
CallCredentials.applyRequestMetadata()
.Utility to record call metrics for load-balancing.
The collection of runtime options for a new RPC call.
Key for a key-value pair.
A refinement of StreamObserver provided by the GRPC runtime to the application (the client or
the server) that allows for more complex interactions with call behavior.
A collection of call stats for channelz.
Command sent from a Netty client stream to the handler to cancel the stream.
Command sent from a Netty server stream to the handler to cancel the stream.
Contains certificate/key PEM file utility method(s).
A virtual connection to a conceptual endpoint, to perform RPCs.
Channel is a logical grouping of channels, subchannels, and sockets.
Channel is a logical grouping of channels, subchannels, and sockets.
These come from the specified states in this document:
https://github.com/grpc/grpc/blob/master/doc/connectivity-semantics-and-api.md
These come from the specified states in this document:
https://github.com/grpc/grpc/blob/master/doc/connectivity-semantics-and-api.md
Protobuf enum
grpc.channelz.v1.ChannelConnectivityState.State
Represents a security configuration to be used for channels.
Channel data is data related to a specific Channel or Subchannel.
Channel data is data related to a specific Channel or Subchannel.
A Channel-specific logger provided by GRPC library to
LoadBalancer
implementations.Log levels.
ChannelRef is a reference to a Channel.
ChannelRef is a reference to a Channel.
ChannelTrace represents the recent events that have occurred on the channel.
ChannelTrace represents the recent events that have occurred on the channel.
A trace event is an interesting thing that happened to a channel or
subchannel, such as creation, address resolution, subchannel creation, etc.
A trace event is an interesting thing that happened to a channel or
subchannel, such as creation, address resolution, subchannel creation, etc.
The supported severity levels of trace events.
Tracks a collections of channel tracing events for a channel/subchannel.
Channelz is a service exposed by gRPC servers that provides detailed debug
information.
Channelz is a service exposed by gRPC servers that provides detailed debug
information.
A stub to allow clients to do synchronous rpc calls to service Channelz.
A stub to allow clients to do ListenableFuture-style rpc calls to service Channelz.
Base class for the server implementation of the service Channelz.
A stub to allow clients to do asynchronous rpc calls to service Channelz.
A static utility class for turning internal data structures into protos.
The channelz service provides stats about a running gRPC process.
Deprecated.
Factory to create
LoadBalancer.ResolvedAddresses
from child load-balancers.A delegating
LoadBalancer.Helper
for the child load blanacer.Provides a list of
ChannelCredentials
, where any one may be used.Provides a list of
ServerCredentials
, where any one may be used.An instance of a call to a remote method.
Callbacks for receiving metadata, response messages and completion status from the server.
Implementation of
ClientCall
.Provider of
ClientStream
s.Utility functions for processing different call idioms.
Convert events on a
ClientCall.Listener
into a blocking Iterator
.Completes a
ClientCalls.GrpcFuture
using StreamObserver
events.A refinement of
CallStreamObserver
that allows for lower-level interaction with
client calls.Protobuf type
grpc.binarylog.v1.ClientHeader
Protobuf type
grpc.binarylog.v1.ClientHeader
Interface for intercepting outgoing calls before they are dispatched by a
Channel
.Utility methods for working with
ClientInterceptor
s.A
ForwardingClientCall
that delivers exceptions from its start logic to the
call listener.Specialization of
StreamObserver
implemented by clients in order to interact with the
advanced features of a call such as flow-control.
Contains client level statistics that are useful to load balancing.
Contains client level statistics that are useful to load balancing.
Contains the number of calls finished for a particular load balance token.
Contains the number of calls finished for a particular load balance token.
Extension of
Stream
to support client-side termination semantics.An observer of client-side stream events.
The progress of the RPC when client stream listener is closed.
StreamTracer
for the client-side.Factory class for
ClientStreamTracer
.Information about a stream.
Builds
ClientStreamTracer.StreamInfo
objects.The client-side transport typically encapsulating a single connection to a remote
server.
A callback that is invoked when the acknowledgement to a
ClientTransport.ping(io.grpc.internal.ClientTransport.PingCallback, java.util.concurrent.Executor)
is received.Pre-configured factory for creating
ConnectionClientTransport
instances.Listens on the client transport life-cycle events.
Maintainer of transport lifecycle status.
Encloses classes related to the compression and decompression of messages.
A gzip compressor and decompressor.
The "identity", or "none" codec.
Uses multiple
CallCredentials
as if they were one.ChannelCredentials
which use per-RPC CallCredentials
.A
ReadableBuffer
that is composed of 0 or more ReadableBuffer
s.A simple read operation to perform on a single
ReadableBuffer
.Represents a message compressor.
Encloses classes related to the compression and decompression of messages.
Provides hooks for modifying gRPC channels and servers during their construction.
A registry for
Configurator
instances.A
ManagedClientTransport
that is based on a connection.The connectivity states.
A tuple of a
ConnectivityState
and its associated Status
.Manages connectivity states of the channel.
Utility to load dynamically Conscrypt when it is available.
A context propagation mechanism which can carry scoped-values across API boundaries and between
threads.
A context which inherits cancellation from its parent but which can also be independently
cancelled and which will propagate cancellation to its descendants.
A listener notified on context cancellation.
Stores listener and executor pair.
Key for indexing values stored in a context.
Defines the mechanisms for attaching and detaching the "current" context.
Utility base implementation of
Runnable
that performs the same function as
Context.wrap(Runnable)
without requiring the construction of an additional object.Utility methods for working with
Context
s in GRPC.Implementation of
ForwardingServerCallListener
that attaches a context before
dispatching calls to the delegate and detaches them after the call completes.A command to create a new stream.
An absolute point in time, generally for tracking when a task should be completed.
Time source representing nanoseconds since fixed but arbitrary point in time.
Represents a message decompressor.
Encloses classes related to the compression and decompression of messages.
Information about a decompressor.
Interface for deframing gRPC messages.
A call that queues requests before a real call is ready to be delegated to.
A client transport that queues requests before a real transport is available.
A stream that queues requests before the transport is available, and delegates to a real stream
implementation when the transport is available.
An extension of
InputStream
that allows the underlying data source to be detached and
transferred to a new instance of the same kind.A DNS-based
NameResolver
.AddressResolver resolves a hostname into a list of addresses.
Used as a DNS-based name resolver's internal representation of resolution result.
DnsNameResolver.ResourceResolver
is a Dns ResourceRecord resolver.DnsNameResolver.ResourceResolverFactory
is a factory for making resource resolvers.Describes a parsed SRV record.
A provider for
DnsNameResolver
.Represents a double-valued counter metric instrument.
Represents a double-valued histogram metric instrument.
Extension to an
InputStream
or alike by adding a method that transfers all
content to an OutputStream
.The reason for dropping a request as instructed by the remote balancer.
A group of
SocketAddress
es that are considered equivalent when channel makes connections.Annotation for
EquivalentAddressGroup
's attributes.
The error code and error message sent by the server when an error occurs.
The error code and error message sent by the server when an error occurs.
The error code and error message sent by the server when an error occurs.
The error code and error message sent by the server when an error occurs.
Indicates a public API that can change at any time, and has no guarantee of API stability and
backward-compatibility.
Retry Policy for Transport reconnection.
A list of extension numbers sent by the server answering
all_extension_numbers_of_type request.
A list of extension numbers sent by the server answering
all_extension_numbers_of_type request.
A list of extension numbers sent by the server answering
all_extension_numbers_of_type request.
A list of extension numbers sent by the server answering
all_extension_numbers_of_type request.
The type name and extension number sent by the client when requesting
file_containing_extension.
The type name and extension number sent by the client when requesting
file_containing_extension.
The type name and extension number sent by the client when requesting
file_containing_extension.
The type name and extension number sent by the client when requesting
file_containing_extension.
An implementation of
ClientStream
that fails (by calling ClientStreamListener.closed(io.grpc.Status, io.grpc.internal.ClientStreamListener.RpcProgress, io.grpc.Metadata)
) when started, and silently does nothing for the other operations.A client transport that creates streams that will immediately fail when started.
Protobuf type
grpc.lb.v1.FallbackResponse
Protobuf type
grpc.lb.v1.FallbackResponse
Serialized FileDescriptorProto messages sent by the server answering
a file_by_filename, file_containing_symbol, or file_containing_extension
request.
Serialized FileDescriptorProto messages sent by the server answering
a file_by_filename, file_containing_symbol, or file_containing_extension
request.
Serialized FileDescriptorProto messages sent by the server answering
a file_by_filename, file_containing_symbol, or file_containing_extension
request.
Serialized FileDescriptorProto messages sent by the server answering
a file_by_filename, file_containing_symbol, or file_containing_extension
request.
A KeyManagerFactory that returns a fixed list of key managers.
An object pool that always returns the same instance and does nothing when returning the object.
A TrustManagerFactory that returns a fixed list of trust managers.
A command to trigger close and close all streams.
A
ManagedChannelBuilder
that delegates all its builder methods to another builder by
default.A
ManagedChannelBuilder
that delegates all its builder methods to another builder by
default.A
ClientCall
which forwards all of its methods to another ClientCall
.A simplified version of
ForwardingClientCall
where subclasses can pass in a ClientCall
as the delegate.A
ClientCall.Listener
which forwards all of its methods to another ClientCall.Listener
.A simplified version of
ForwardingClientCallListener
where subclasses can pass in a
ClientCall.Listener
as the delegate.Forwards listener callbacks to a delegate.
A forwarding class to ensure non overridden methods are forwarded to the delegate.
Base class for a wrapper around another
ReadableBuffer
.A
ServerBuilder
that delegates all its builder methods to another builder by default.A
ServerCall
which forwards all of its methods to another ServerCall
.A simplified version of
ForwardingServerCall
where subclasses can pass in a ServerCall
as the delegate.A
ServerCall.Listener
which forwards all of its methods to another ServerCall.Listener
of matching parameterized types.A simplified version of
ForwardingServerCallListener
where subclasses can pass in a
ServerCall.Listener
as the delegate.Interface for framing gRPC messages.
Protobuf type
grpc.channelz.v1.GetChannelRequest
Protobuf type
grpc.channelz.v1.GetChannelRequest
Protobuf type
grpc.channelz.v1.GetChannelResponse
Protobuf type
grpc.channelz.v1.GetChannelResponse
Protobuf type
grpc.channelz.v1.GetServerRequest
Protobuf type
grpc.channelz.v1.GetServerRequest
Protobuf type
grpc.channelz.v1.GetServerResponse
Protobuf type
grpc.channelz.v1.GetServerResponse
Protobuf type
grpc.channelz.v1.GetServerSocketsRequest
Protobuf type
grpc.channelz.v1.GetServerSocketsRequest
Protobuf type
grpc.channelz.v1.GetServerSocketsResponse
Protobuf type
grpc.channelz.v1.GetServerSocketsResponse
Protobuf type
grpc.channelz.v1.GetServersRequest
Protobuf type
grpc.channelz.v1.GetServersRequest
Protobuf type
grpc.channelz.v1.GetServersResponse
Protobuf type
grpc.channelz.v1.GetServersResponse
Protobuf type
grpc.channelz.v1.GetSocketRequest
Protobuf type
grpc.channelz.v1.GetSocketRequest
Protobuf type
grpc.channelz.v1.GetSocketResponse
Protobuf type
grpc.channelz.v1.GetSocketResponse
Protobuf type
grpc.channelz.v1.GetSubchannelRequest
Protobuf type
grpc.channelz.v1.GetSubchannelRequest
Protobuf type
grpc.channelz.v1.GetSubchannelResponse
Protobuf type
grpc.channelz.v1.GetSubchannelResponse
Protobuf type
grpc.channelz.v1.GetTopChannelsRequest
Protobuf type
grpc.channelz.v1.GetTopChannelsRequest
Protobuf type
grpc.channelz.v1.GetTopChannelsResponse
Protobuf type
grpc.channelz.v1.GetTopChannelsResponse
A command to trigger close.
A command to trigger close and allow streams naturally close.
A load balancer that gracefully swaps to a new lb policy.
Stuff that are part of the public API but are not bound to particular classes, e.g., static
methods, constants, attribute and context keys.
Annotation for transport attributes.
Special attributes that are only useful to gRPC.
Annotates that the class is gRPC-generated code to assist
Java Annotation Processors.
gRPC wrapper for
Http2ConnectionHandler
.A headers utils providing custom gRPC implementations of
DefaultHttp2HeadersDecoder
.A
Http2Headers
implementation optimized for inbound/received headers.A
GrpcHttp2HeadersUtils.GrpcHttp2InboundHeaders
implementation, optimized for HTTP/2 request headers.This class only implements the methods used by
NettyClientHandler
and tests.A custom implementation of Http2Headers that only includes methods used by gRPC.
A GrpcKeyBuilder applies to a given gRPC service, name, and headers.
A GrpcKeyBuilder applies to a given gRPC service, name, and headers.
If you wish to include the host, service, or method names as keys in the
generated RouteLookupRequest, specify key names to use in the extra_keys
submessage.
If you wish to include the host, service, or method names as keys in the
generated RouteLookupRequest, specify key names to use in the extra_keys
submessage.
To match, one of the given Name fields must match; the service and method
fields are specified as fixed strings.
To match, one of the given Name fields must match; the service and method
fields are specified as fixed strings.
Record and aggregate client-side load data for GRPCLB.
Constants for the GRPCLB load-balancer.
A
LoadBalancer
that uses the GRPCLB protocol.The provider for the "grpclb" balancing policy.
A DNS-based
NameResolver
with gRPC LB specific add-ons for resolving balancer
addresses via service records.The states of a GRPCLB working session of
GrpclbLoadBalancer
.
Log entry we store in binary logs
Log entry we store in binary logs
Enumerates the type of event
Note the terminology is different from the RPC semantics
definition, but the same meaning is expressed here.
Enumerates the entity that generates the log entry
A simple servlet backed by a gRPC server.
A simple servlet backed by a gRPC server.
Utility for configuring SslContext for gRPC.
Common utilities for GRPC.
Percent encode the
authority
based on
https://datatracker.ietf.org/doc/html/rfc3986#section-3.2.All error codes identified by the HTTP/2 spec.
Marshals a nanoseconds representation of the timeout to and from a string representation,
consisting of an ASCII decimal representation of a number with at most 8 digits, followed by a
unit.
Processes gzip streams, delegating to
Inflater
to perform on-demand inflation of the
deflated blocks.Registry of services and their methods used by servers to dispatching incoming calls.
Extension to an
InputStream
whose content can be accessed as ByteBuffer
s.Wraps a
LoadBalancer
and implements the client-side health-checking
(https://github.com/grpc/proposal/blob/master/A17-client-side-health-checking.md).Utility for enabling
client-side health checking for
LoadBalancer
s.The health-check-capable provider for the "round_robin" balancing policy.
Protobuf type
grpc.health.v1.HealthCheckRequest
Protobuf type
grpc.health.v1.HealthCheckRequest
Protobuf type
grpc.health.v1.HealthCheckResponse
Protobuf type
grpc.health.v1.HealthCheckResponse
Protobuf enum
grpc.health.v1.HealthCheckResponse.ServingStatus
A stub to allow clients to do synchronous rpc calls to service Health.
A stub to allow clients to do ListenableFuture-style rpc calls to service Health.
Base class for the server implementation of the service Health.
A stub to allow clients to do asynchronous rpc calls to service Health.
A new
LoadBalancer.Helper
used by health producer systems to build health
notification chain, via LoadBalancer.CreateSubchannelArgs
.A
HealthStatusManager
object manages a health check service.Deprecated.
Use
HealthStatusManager
instead.Hedging policy data object.
Base implementation for client streams using HTTP2 as the transport.
DecoratingHttp2ConnectionEncoder
which guards against a remote peer that will trigger a massive amount
of control frames but will not consume our responses to these.Represents an outstanding PING operation on an HTTP/2 channel.
An
ProxiedSocketAddress
for making a connection to an endpoint via an HTTP CONNECT proxy.The builder for
HttpConnectProxiedSocketAddress
.
An HttpKeyBuilder applies to a given HTTP URL and headers.
An HttpKeyBuilder applies to a given HTTP URL and headers.
Protobuf type
grpc.lb.v1.InitialLoadBalanceRequest
Protobuf type
grpc.lb.v1.InitialLoadBalanceRequest
Protobuf type
grpc.lb.v1.InitialLoadBalanceResponse
Protobuf type
grpc.lb.v1.InitialLoadBalanceResponse
Builder for a channel that issues in-process requests.
Creates InProcess transports.
Builder for a server that services in-process requests.
Custom SocketAddress class for
InProcessTransport
.No client identity, authentication, or encryption is to be used.
An insecure credential that upgrades from HTTP/1 to HTTP/2.
No server identity or encryption is to be used.
Builds a concise and readable string that gives insight of the concerned part of the system.
Annotates a program element (class, method, package, etc) which is internal to gRPC, not part of
the public API, and should not be used by users of gRPC.
Internal
CallMetricRecorder
accessor.Internal accessor for
CallOptions
.This is an internal API.
A data class to represent a channel's stats.
A data class to represent transport stats.
Internal
ClientCalls
accessor.Companion enum for internal enum
ClientCalls.StubType
.Internal accessor.
Per method config selector that the channel or load balancers will use to choose the appropriate
config or take config related actions for an RPC.
Internal access to Configurator API.
Access internal global configurators.
Private accessor for decompressor registries.
Internal accessor for
GracefulServerCloseCommand
.Internal
GrpclbConstants
accessor.Internal
InProcessChannelBuilder
accessor.Internal
InProcessServerBuilder
accessor.An internal class.
All known transports.
An internal class.
Internal accessors for
ManagedChannelBuilder
.Internal accessor for
ManagedChannelProvider
.Internal
Metadata
accessor.A specialized plain ASCII marshaller.
Accesses internal data and methods.
Internal
CallMetricRecorder
accessor.Internal
NettyChannelBuilder
accessor.A class that provides a Netty handler to control protocol negotiation.
Internal
NettyChannelCredentials
accessor.Internal
NettyServerBuilder
accessor.Internal
NettyServerCredentials
accessor.An internal accessor.
Internal accessor for
ProtocolNegotiationEvent
.Internal accessor for
InternalProtocolNegotiator.ProtocolNegotiator
.Internal accessor for
ProtocolNegotiators
.An object that accepts new incoming connections on one or more listening socket addresses.
Accessor to internal methods of
ServerInterceptors
.Internal accessor for
ServerProvider
.Accesses internal data.
Transports for a single
SocketAddress
.Index as in 'i', the pointer to an entry.
An internal class.
An internal class.
Utility class for
WriteBufferingAndExceptionHandler
.Aggregates the in-use state of a set of objects.
Utility class for determining support for Jetty TLS ALPN/NPN.
JndiResourceResolverFactory
resolves additional records for the DnsNameResolver.Parses JSON with as few preconceived notions as possible.
Helper utility to work with JSON values in Java types.
Monitors the client's PING usage to make sure the rate is permitted.
Manages keepalive pings.
Default client side
KeepAliveManager.KeepAlivePinger
.An
InputStream
or alike whose total number of bytes that can be read is known
upfront.Configuration for RLS load balancing policy.
Listener for child lb status change events.
ChildLoadBalancingPolicy is an elected child policy to delegate requests.
ChildPolicyWrapper is a wrapper class for child load balancing policy with associated helper /
utility classes to manage the child policy.
Exception thrown when attempting to parse child policy encountered parsing issue.
Factory for
LbPolicyConfiguration.ChildPolicyWrapper
.A LinkedHashLruCache implements least recently used caching where it supports access order lru
cache eviction while allowing entry level expiration time.
A list of ServiceResponse sent by the server answering list_services request.
A list of ServiceResponse sent by the server answering list_services request.
A list of ServiceResponse sent by the server answering list_services request.
A list of ServiceResponse sent by the server answering list_services request.
A pluggable component that receives resolved addresses from
NameResolver
and provides the
channel a usable subchannel when asked.Arguments for creating a
LoadBalancer.Subchannel
.Key for a key-value pair.
Deprecated.
Use
new FixedResultPicker(PickResult.withError(error))
instead.Factory to create
LoadBalancer
instance.A picker that always returns the same result.
Provides essentials for LoadBalancer implementations.
Receives information about the pick being chosen.
A balancing decision made by
SubchannelPicker
for an RPC.Provides arguments for a
LoadBalancer.SubchannelPicker.pickSubchannel(LoadBalancer.PickSubchannelArgs)
.Represents a combination of the resolved server address, associated attributes and a load
balancing policy config.
Builder for
LoadBalancer.ResolvedAddresses
.A logical connection to a server, or a group of equivalent servers represented by an
EquivalentAddressGroup
.The main balancing logic.
Receives state changes for one
LoadBalancer.Subchannel
.Protobuf type
grpc.lb.v1.LoadBalanceRequest
Protobuf type
grpc.lb.v1.LoadBalanceRequest
Protobuf type
grpc.lb.v1.LoadBalanceResponse
Protobuf type
grpc.lb.v1.LoadBalanceResponse
A stub to allow clients to do synchronous rpc calls to service LoadBalancer.
A stub to allow clients to do ListenableFuture-style rpc calls to service LoadBalancer.
Base class for the server implementation of the service LoadBalancer.
A stub to allow clients to do asynchronous rpc calls to service LoadBalancer.
Provider of
LoadBalancer
s.Registry of
LoadBalancerProvider
s.A simple wrapper for a
Runnable
that logs any exception thrown by it, before
re-throwing it.An interface for a long base counter.
A factory for creating
LongCounter
objects.Represents a long-valued counter metric instrument.
Represents a long-valued gauge metric instrument.
Represents a long-valued histogram metric instrument.
An LruCache is a cache with least recently used eviction.
A Listener notifies cache eviction events.
Type of cache eviction.
A
Channel
that provides lifecycle management.A builder for
ManagedChannel
instances.Internal-only.
A communication channel for making outgoing RPCs.
A client call for a given channel that applies a given config selector when it starts.
Lazily request for Executor from an executor pool.
A ResolutionState indicates the status of last name resolution.
Default managed channel builder, for usage in Transport implementations.
An interface for Transport implementors to provide a default port to
NameResolver
for use in cases where the target string doesn't include a port.An interface for Transport implementors to provide the
ClientTransportFactory
appropriate for the channel.Default implementation of
ManagedChannelImplBuilder.ChannelBuilderDefaultPortProvider
that returns a fixed port.Convenience ClientTransportFactoryBuilder, throws UnsupportedOperationException().
Best effort detecting channels that has not been properly cleaned up.
Provider of managed channels for transport agnostic consumption.
Thrown when no suitable
ManagedChannelProvider
objects can be found.Registry of
ManagedChannelProvider
s.Thrown when no suitable
ManagedChannelProvider
objects can be found.ManagedChannelServiceConfig
is a fully parsed and validated representation of service
configuration data.Equivalent of MethodConfig from a ServiceConfig with restrictions from Channel setting.
A
ClientTransport
that has life-cycle management.Receives notifications for the transport life-cycle events.
Monitors connection idle time; shutdowns the connection if the max connection idle is reached.
Message payload, used by CLIENT_MESSAGE and SERVER_MESSAGE
Message payload, used by CLIENT_MESSAGE and SERVER_MESSAGE
Deframer for GRPC frames.
A listener of deframing events.
An
InputStream
that enforces the MessageDeframer.SizeEnforcingInputStream.maxMessageSize
limit for compressed frames.Encodes gRPC messages to be delivered via the transport layer which implements
MessageFramer.Sink
.Sink implemented by the transport layer to receive frames and forward them to their
destination.
A list of metadata pairs, used in the payload of client header,
server header, and server trailer.
Provides access to read and write metadata values to be exchanged during a call.
Marshaller for metadata values that are serialized into ASCII strings.
Marshaller for metadata values that are serialized into raw binary.
Marshaller for metadata values that are serialized to an InputStream.
A list of metadata pairs, used in the payload of client header,
server header, and server trailer.
Key for metadata entries.
A binary key for values which should be serialized lazily to
InputStream
s.Internal holder for values which are serialized/de-serialized lazily.
A specialized plain ASCII marshaller.
A metadata key value pair
A metadata key value pair
Utility functions for binding and receiving headers.
Description of a remote method used by
Channel
to initiate a call.A builder for a
MethodDescriptor
.A typed abstraction over message serialization and deserialization, a.k.a.
The call type of a method.
A marshaller that uses a fixed instance of the type it produces.
A marshaller that supports retrieving its type parameter
T
at runtime.Represents a metric instrument.
A registry for globally registered metric instruments.
An interface used for recording gRPC metrics.
Implements the service/APIs for Out-of-Band metrics reporting, only for utilization metrics.
Callback to record gauge values.
Recorder for instrument values produced by a batch callback.
A handle to a registration, that allows unregistration.
Utility helper class to check whether values for
CallMetricRecorder
and
MetricRecorder
are inside the valid range.Provides a central point for gRPC components to record metric values.
Recorder for instrument values produced by a batch callback.
A gRPC object of orca load report.
An internal interface representing a receiver or aggregator of gRPC metrics data.
A deframer that moves decoding between the transport and app threads based on which is more
efficient at that moment.
A base load balancing policy for those policies which has multiple children such as
ClusterManager or the petiole policies.
Endpoint is an optimization to quickly lookup and compare EquivalentAddressGroup address sets.
Default implementation of
HandlerRegistry
.
Extract a key based on a given name (e.g.
Extract a key based on a given name (e.g.
A pluggable component that resolves a target
URI
and return addresses to the caller.Information that a
NameResolver.Factory
uses to create a NameResolver
.Builder for
NameResolver.Args
.Represents either a successfully parsed service config, containing all necessary parts to be
later applied by the channel, or a Status containing the error encountered while parsing.
Factory that creates
NameResolver
instances.Receives address updates.
Receives address updates.
Represents the results from a Name Resolver.
A builder for
NameResolver.ResolutionResult
.Annotation for name resolution result attributes.
Parses and validates service configuration.
Provider of name resolvers for name agnostic consumption.
Registry of
NameResolverProvider
s.Identifies the negotiation used for starting up HTTP/2.
"Adaptive" cumulator: cumulate
ByteBuf
s by dynamically switching between merge and
compose strategies.A builder to help simplify construction of channels using the Netty transport.
This class is meant to be overriden with a custom implementation of
NettyChannelBuilder.LocalSocketPicker.createSocketAddress(java.net.SocketAddress, io.grpc.Attributes)
.Creates Netty transports.
A credential with full control over the security handshake.
Provider for
NettyChannelBuilder
instances.Client-side Netty handler for GRPC processing.
Client stream for a Netty transport.
This should only be called from the transport thread.
A Netty-based
ConnectionClientTransport
implementation.A
Buffer
implementation that is backed by a Netty ByteBuf
.Netty-based server implementation.
A class that can answer channelz queries about the server listen sockets.
A builder to help simplify the construction of a Netty-based GRPC server.
A credential with full control over the security handshake.
Server-side Netty handler for GRPC processing.
Provider for
NettyServerBuilder
instances.Server stream for a Netty HTTP2 transport.
This should only be called from the transport thread.
The Netty-based server transport.
An class for getting low level socket info.
A TcpInfo and additional other info that will be turned into channelz socket options.
A credential that performs TLS with Netty's SslContext as configuration.
A credential that performs TLS with Netty's SslContext as configuration.
The
WritableBuffer
used by the Netty transport.The default allocator for
NettyWritableBuffer
s used by the Netty transport.An implementation of
ClientStream
that silently does nothing for the operations.An object pool.
A ManagedChannel backed by a single
InternalSubchannel
and used for LoadBalancer
to its own RPC needs.Wraps a child
LoadBalancer
while monitoring for outlier backends and removing them from
the use of the child LB.Tracks additional information about the endpoint needed for outlier detection.
Tracks both successful and failed call counts.
Maintains a mapping from endpoint (a set of addresses) to their trackers.
The configuration for
OutlierDetectionLoadBalancer
.The configuration for failure percentage ejection.
For building new
OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig.FailurePercentageEjection
instances.The configuration for success rate ejection.
Builds new instances of
OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig.SuccessRateEjection
.Implementations provide different ways of ejecting outlier addresses..
This algorithm ejects addresses that don't maintain a required rate of successful calls.
A
ClientCall
which forwards all of its methods to another ClientCall
which
may have a different sendMessage() message type.A
ClientCall.Listener
which forwards all of its methods to another ClientCall.Listener
which may have a different parameterized type than the
onMessage() message type.A
ServerCall
which forwards all of it's methods to another ServerCall
which
may have a different sendMessage() message type.A
ServerCall.Listener
which forwards all of its methods to another ServerCall.Listener
which may have a different parameterized type than the
onMessage() message type.A partial implementation of the
MetricInstrument
interface.A persistent (copy-on-write) hash tree/trie.
Adapter for tracers into details consumers.
A
LoadBalancer
that provides no load-balancing over the addresses from the NameResolver
.Index as in 'i', the pointer to an entry.
No-op picker which doesn't add any custom picking logic.
A
LoadBalancer
that provides no load-balancing over the addresses from the NameResolver
.No-op picker which doesn't add any custom picking logic.
Provider for the "pick_first" balancing policy.
Implementation of
LoadBalancer.PickSubchannelArgs
.Represents a completion of a protocol negotiation stage.
An class that provides a Netty handler to control protocol negotiation.
Common
ProtocolNegotiator
s used by gRPC.Adapts a
ProtocolNegotiationEvent
to the GrpcHttp2ConnectionHandler
.A tuple of (host, port).
Acts as a combination of Http2Upgrade and
ProtocolNegotiators.GrpcNegotiationHandler
.A negotiator that only does plain text.
ProtocolNegotiationHandler is a convenience handler that makes it easy to follow the rules for
protocol negotiation.
A Proxy handler follows
ProtocolNegotiators.ProtocolNegotiationHandler
pattern.Waits for the channel to be active, and then installs the next Handler.
Provides access to the underlying proto file descriptor.
An
InputStream
backed by a protobuf.Utility methods for using protobuf with grpc.
Provides access to the underlying proto service method descriptor.
Provides a reflection service for Protobuf services (including the reflection service itself).
Provides a reflection service for Protobuf services (including the reflection service itself).
Provides a set of methods for answering reflection queries for the file descriptors underlying
a set of services.
Indexes the server's services and allows lookups of file descriptors by filename, symbol, type,
and extension number.
Provides access to the underlying proto service descriptor.
Utility methods for using protobuf with grpc.
An address that contains the information about making a connection via a proxy.
A utility class to detect which proxy, if any, should be used for a given
SocketAddress
.A utility class that detects proxies using
ProxySelector
and detects authentication
credentials using Authenticator
.This interface makes unit testing easier by avoiding direct calls to static methods.
Interface for an abstract byte buffer.
Utility methods for creating
ReadableBuffer
instances.An
InputStream
that is backed by a ReadableBuffer
.A
ReadableBuffer
that is backed by a byte array.A
ReadableBuffer
that is backed by a ByteBuffer
.A
.
LongCounter
that is implemented with a JDK8
invalid reference
LongAdder
Reschedules a runnable lazily.
A factory to create
LoadBalancer.ResolvedAddresses
.A logical
ClientStream
that is retriable.Used to keep track of the total amount of memory used to buffer retryable or hedged RPCs for
the Channel.
Allows cancelling a Future without racing with setting the future.
A wrapper of a physical stream of a retry/hedging attempt, that comes with some useful
attributes.
Used for retry throttling.
This wrapper class can add retry capability to any polling
NameResolver
implementation
that supports calling RetryingNameResolver.ResolutionResultListener
s with the outcome of each resolution.Retry policy data object.
This interface is used to schedule future retry attempts for a failed operation.
Implementation of
LoadBalancer
backed by route lookup service.Provides
CachingRlsLbClient.Builder
with default settings.The provider for the "rls_experimental" balancing policy.
RlsProtoConverters is a collection of
Converter
between RouteLookupService proto / json
messages to internal representation in RlsProtoData
.RouteLookupConfigConverter converts between json map to
RlsProtoData.RouteLookupConfig
.RouteLookupRequestConverter converts between
RouteLookupRequest
and RlsProtoData.RouteLookupRequest
.RouteLookupResponseConverter converts between
RouteLookupResponse
and RlsProtoData.RouteLookupResponse
.RlsProtoData is a collection of internal representation of RouteLookupService proto messages.
GrpcKeyBuilder is a configuration to construct headers consumed by route lookup service.
Name represents a method for a given service.
NameMatcher extract a key based on a given name (e.g.
A config object for gRPC RouteLookupService.
A request object sent to route lookup service.
A response from route lookup service.
A RlsRequestFactory creates
RlsProtoData.RouteLookupRequest
using key builder map from RlsProtoData.RouteLookupConfig
.A
LoadBalancer
that provides round-robin load-balancing over the EquivalentAddressGroup
s from the NameResolver
.
RouteLookupClusterSpecifier is used in xDS to represent a cluster specifier
plugin for RLS.
RouteLookupClusterSpecifier is used in xDS to represent a cluster specifier
plugin for RLS.
Protobuf type
grpc.lookup.v1.RouteLookupConfig
Protobuf type
grpc.lookup.v1.RouteLookupConfig
Protobuf type
grpc.lookup.v1.RouteLookupRequest
Protobuf type
grpc.lookup.v1.RouteLookupRequest
Possible reasons for making a request.
Protobuf type
grpc.lookup.v1.RouteLookupResponse
Protobuf type
grpc.lookup.v1.RouteLookupResponse
A stub to allow clients to do synchronous rpc calls to service RouteLookupService.
A stub to allow clients to do ListenableFuture-style rpc calls to service RouteLookupService.
Base class for the server implementation of the service RouteLookupService.
A stub to allow clients to do asynchronous rpc calls to service RouteLookupService.
RpcMethod
contains a limited subset of information about the RPC to assist
Java Annotation Processors.The library built-in implementation of service config parser.
A provider for
io.grpc.grpclb.GrpclbNameResolver
.Provider for the "round_robin" balancing policy.
Security represents details about how secure the socket is.
Security represents details about how secure the socket is.
Protobuf type
grpc.channelz.v1.Security.OtherSecurity
Protobuf type
grpc.channelz.v1.Security.OtherSecurity
Protobuf type
grpc.channelz.v1.Security.Tls
Protobuf type
grpc.channelz.v1.Security.Tls
The level of security guarantee in communications.
Command sent from the transport to the Netty channel to send a GRPC frame to the remote endpoint.
Command sent from the transport to the Netty channel to send a PING frame.
Command sent from the transport to the Netty channel to send response headers to the client.
Executes a task directly in the calling thread, unless it's a reentrant call in which case the
task is enqueued and executed once the calling task completes.
Server represents a single server.
Contains server information.
Server for listening for and dispatching incoming calls.
Server represents a single server.
Contains server information.
A builder for
Server
instances.Encapsulates a single call received from a remote client.
Callbacks for consuming incoming RPC messages.
Defines what executor handles the server call, based on each RPC call information at runtime.
Interface to initiate processing of incoming remote calls.
All of these callbacks are assumed to called on an application thread, and the caller is
responsible for handling thrown exceptions.
An implementation of
ServerStreamTracer.ServerCallInfo
.Utility functions for adapting
ServerCallHandler
s to application service implementation,
meant to be used by the generated code.Adaptor to a bidirectional streaming method.
Adaptor to a client streaming method.
No-op implementation of StreamObserver.
Adaptor to a server streaming method.
Adaptor to a unary call method.
A refinement of
CallStreamObserver
to allows for interaction with call
cancellation events on the server side.Represents a security configuration to be used for servers.
ServerData is data for a specific Server.
ServerData is data for a specific Server.
Protobuf type
grpc.binarylog.v1.ServerHeader
Protobuf type
grpc.binarylog.v1.ServerHeader
Default implementation of
Server
, for creation by transports.Dispatches callbacks onto an application-provided executor and correctly propagates
exceptions.
Default builder for
Server
instances, for usage in Transport implementations.An interface to provide to provide transport specific information for the server.
Interface for intercepting incoming calls before they are dispatched by
ServerCallHandler
.Utility methods for working with
ServerInterceptor
s.BufferedInputStream
that also implements KnownLength
.Protobuf type
grpc.lb.v1.ServerList
Protobuf type
grpc.lb.v1.ServerList
A listener to a server for transport creation events.
Definition of a method exposed by a
Server
.Provider of servers for transport agnostic consumption.
ServerRef is a reference to a Server.
ServerRef is a reference to a Server.
A stub to allow clients to do synchronous rpc calls to service ServerReflection.
A stub to allow clients to do synchronous rpc calls to service ServerReflection.
A stub to allow clients to do ListenableFuture-style rpc calls to service ServerReflection.
A stub to allow clients to do ListenableFuture-style rpc calls to service ServerReflection.
Base class for the server implementation of the service ServerReflection.
Base class for the server implementation of the service ServerReflection.
A stub to allow clients to do asynchronous rpc calls to service ServerReflection.
A stub to allow clients to do asynchronous rpc calls to service ServerReflection.
Deprecated.
The message sent by the client when calling ServerReflectionInfo method.
The message sent by the client when calling ServerReflectionInfo method.
The message sent by the client when calling ServerReflectionInfo method.
The message sent by the client when calling ServerReflectionInfo method.
The message sent by the server to answer ServerReflectionInfo method.
The message sent by the server to answer ServerReflectionInfo method.
The message sent by the server to answer ServerReflectionInfo method.
The message sent by the server to answer ServerReflectionInfo method.
Registry of
ServerProvider
s.Thrown when no suitable
ServerProvider
objects can be found.Definition of a service to be exposed via a Server.
Builder for constructing Service instances.
Extension of
Stream
to support server-side termination semantics.An observer of server-side stream events.
Listens to events on a stream to collect metrics.
Deprecated.
Will be deleted when
ServerStreamTracer.serverCallStarted(ServerCall)
is removed.A data class with info about the started
ServerCall
.An inbound connection.
Listens on server transport life-cycle events, with the capability to read and/or change
transport attributes.
A observer of a server-side transport for stream creation events.
ServiceConfigState
holds the state of the current service config.Helper utility to work with service configs.
A LoadBalancingConfig that includes the policy name (the key) and its raw config value (parsed
JSON).
Descriptor for a service.
A builder for a
ServiceDescriptor
.An interface that allows us to get priority information about a provider.
The information of a single service used by ListServiceResponse to answer
list_services request.
The information of a single service used by ListServiceResponse to answer
list_services request.
The information of a single service used by ListServiceResponse to answer
list_services request.
The information of a single service used by ListServiceResponse to answer
list_services request.
An adapter that transforms
HttpServletRequest
into gRPC request and lets a gRPC server
process it, and transforms the gRPC response into HttpServletResponse
.An adapter that transforms
HttpServletRequest
into gRPC request and lets a gRPC server
process it, and transforms the gRPC response into HttpServletResponse
.Builder to build a gRPC server that can run as a servlet.
Builder to build a gRPC server that can run as a servlet.
A holder for shared resource singletons.
Defines a resource, and the way to create and destroy instances of it.
An ObjectPool backed by a
SharedResourceHolder.Resource
.
Information about an actual connection.
Information about an actual connection.
SocketData is data associated for a specific Socket.
SocketData is data associated for a specific Socket.
SocketOption represents socket options for a socket.
SocketOption represents socket options for a socket.
For use with SocketOption's additional field.
For use with SocketOption's additional field.
For use with SocketOption's additional field.
For use with SocketOption's additional field.
For use with SocketOption's additional field.
For use with SocketOption's additional field.
SocketRef is a reference to a Socket.
SocketRef is a reference to a Socket.
Provides utilities to manage SPIFFE bundles, extract SPIFFE IDs from X.509 certificate chains,
and parse SPIFFE IDs.
Represents a SPIFFE trust bundle; that is, a map from trust domain to set of trusted
certificates.
Represents a SPIFFE ID as defined in the SPIFFE standard.
A delegating Listener that throws away notifications of messagesAvailable() after the deframer
has closed or failed.
The stats and tracing information for a stream.
Defines the status of an operation by providing a standard
Status.Code
in conjunction with an
optional descriptive message.The set of canonical status codes.
Status
in Exception form, for propagating Status information via exceptions.Either a Status or a value.
Utility methods for working with
Status
.Status
in RuntimeException form, for propagating Status information via exceptions.A single stream of communication between two end-points within a transport.
Container for stream ids.
An observer of
Stream
events.A producer for deframed gRPC messages.
Receives notifications from an observable stream of messages.
Deprecated.
Of questionable utility and generally not used.
Listens to events on a stream to collect metrics.
Subchannel is a logical grouping of channels, subchannels, and sockets.
Subchannel is a logical grouping of channels, subchannels, and sockets.
Manages life-cycle of Subchannels for
GrpclbState
.Receives state changes for a pooled
LoadBalancer.Subchannel
.
SubchannelRef is a reference to a Subchannel.
SubchannelRef is a reference to a Subchannel.
SubchannelStateManager manages
ConnectivityState
of child subchannels.Implementation of
SubchannelStateManager
.A synchronization context is a queue of tasks that run in sequence.
Allows the user to check the status and/or cancel a task scheduled by
SynchronizationContext.schedule(java.lang.Runnable, long, java.util.concurrent.TimeUnit, java.util.concurrent.ScheduledExecutorService)
.The output file goes to the JVM's temp dir with a prefix of BINARY_INFO.
A
ThreadLocal
-based context storage implementation.A
Deframer
that optimizations by taking over part of the thread safety.A strategy for deciding when to throttle requests at the client.
Time source representing the current system time in nanos.
TLS credentials, providing server authentication and encryption.
Builder for
TlsChannelCredentials
.Features to understand TLS configuration.
TLS credentials, providing server identity and encryption.
Builder for
TlsServerCredentials
.The level of authentication the server should expect from the client.
Features to understand TLS configuration.
Wraps a
ClientStreamTracer.Factory
, retrieves tokens from transport attributes and
attaches them to headers.Protobuf type
grpc.binarylog.v1.Trailer
Protobuf type
grpc.binarylog.v1.Trailer
A class that intercepts uncaught exceptions of type
StatusRuntimeException
and handles
them by closing the ServerCall
, and transmitting the exception's status and metadata
to the client.A
ServerCall
that wraps around a non thread safe delegate and provides thread safe
access by serializing everything on an executor.Utility functions for transport layer framing.
Provides transports for sending RPCs.
A class for gathering statistics about a transport.
An interface for reading the local and remote flow control windows of the transport.
A container that holds the local and remote flow control window sizes.
Provider for
NettyChannelBuilder
instances for UDS channels.A stand-in provider when you must provide a provider but you don't actually have one.
Common utility methods.
An interface for a byte buffer that can only be written to.
An allocator of buffers provided by the transport implementation to
MessageFramer
so
it can send chunks of data to the transport in a form that the transport can directly serialize.Buffers all writes until either
WriteBufferingAndExceptionHandler.writeBufferedAndRemove(ChannelHandlerContext)
or
WriteBufferingAndExceptionHandler.failWrites(Throwable)
is called.A queue of pending writes to a
Channel
that is flushed as a single unit.Simple wrapper type around a command and its optional completion listener.
ChannelzService
instead.