Uses of Package
io.grpc.internal
-
Packages that use io.grpc.internal Package Description io.grpc.grpclb io.grpc.inprocess The in-process transport which is for when a server is in the same process as the client.io.grpc.internal Interfaces and implementations that are internal to gRPC.io.grpc.netty The main transport implementation based on Netty, for both the client and the server.io.grpc.protobuf.services Service definitions and utilities with protobuf dependency for the pre-defined gRPC services.io.grpc.rls io.grpc.servlet API that implements gRPC server as a servlet.io.grpc.servlet.jakarta API that implements gRPC server as a servlet.io.grpc.util Utilities with advanced features in the core layer that user can optionally use. -
Classes in io.grpc.internal used by io.grpc.grpclb Class Description BackoffPolicy Determines how long to wait before doing some action (typically a retry, or a reconnect).BackoffPolicy.Provider DnsNameResolver A DNS-basedNameResolver
.DnsNameResolver.AddressResolver AddressResolver resolves a hostname into a list of addresses.DnsNameResolver.InternalResolutionResult Used as a DNS-based name resolver's internal representation of resolution result.DnsNameResolver.ResourceResolver DnsNameResolver.ResourceResolver
is a Dns ResourceRecord resolver.SharedResourceHolder.Resource Defines a resource, and the way to create and destroy instances of it.TimeProvider Time source representing the current system time in nanos. -
Classes in io.grpc.internal used by io.grpc.inprocess Class Description ClientStream Extension ofStream
to support client-side termination semantics.ClientStreamListener An observer of client-side stream events.ClientTransport The client-side transport typically encapsulating a single connection to a remote server.ClientTransport.PingCallback A callback that is invoked when the acknowledgement to aClientTransport.ping(io.grpc.internal.ClientTransport.PingCallback, java.util.concurrent.Executor)
is received.ClientTransportFactory Pre-configured factory for creatingConnectionClientTransport
instances.ClientTransportFactory.ClientTransportOptions ClientTransportFactory.SwapChannelCredentialsResult ConnectionClientTransport AManagedClientTransport
that is based on a connection.InsightBuilder Builds a concise and readable string that gives insight of the concerned part of the system.InternalServer An object that accepts new incoming connections on one or more listening socket addresses.InUseStateAggregator Aggregates the in-use state of a set of objects.ManagedChannelImplBuilder Default managed channel builder, for usage in Transport implementations.ManagedClientTransport AClientTransport
that has life-cycle management.ManagedClientTransport.Listener Receives notifications for the transport life-cycle events.ObjectPool An object pool.ServerImplBuilder Default builder forServer
instances, for usage in Transport implementations.ServerListener A listener to a server for transport creation events.ServerStream Extension ofStream
to support server-side termination semantics.ServerStreamListener An observer of server-side stream events.ServerTransport An inbound connection.ServerTransportListener A observer of a server-side transport for stream creation events.StatsTraceContext The stats and tracing information for a stream.Stream A single stream of communication between two end-points within a transport.StreamListener.MessageProducer A producer for deframed gRPC messages. -
Classes in io.grpc.internal used by io.grpc.internal Class Description AbstractClientStream.Sink A sink for outbound operations, separated from the stream simply to avoid name collisions/confusion.AbstractClientStream.TransportState This should only be called from the transport thread.AbstractReadableBuffer Abstract base class forReadableBuffer
implementations.AbstractServerStream.Sink A sink for outbound operations, separated from the stream simply to avoid name collisions/confusion.AbstractServerStream.TransportState This should only be called from the transport thread (except for private interactions withAbstractServerStream
).AbstractStream The stream and stream state as used by the application.AbstractStream.TransportState Stream state as used by the transport.AbstractSubchannel The base interface of the Subchannels returned byLoadBalancer.Helper.createSubchannel(io.grpc.LoadBalancer.CreateSubchannelArgs)
.ApplicationThreadDeframer.InitializingMessageProducer ApplicationThreadDeframer.TransportExecutor ApplicationThreadDeframerListener Listener for when deframing on the application thread, which calls the real listener on the transport thread.ApplicationThreadDeframerListener.TransportExecutor AtomicBackoff.State AutoConfiguredLoadBalancerFactory AutoConfiguredLoadBalancerFactory.AutoConfiguredLoadBalancer AutoConfiguredLoadBalancerFactory.PolicyException BackoffPolicy Determines how long to wait before doing some action (typically a retry, or a reconnect).BackoffPolicy.Provider CallTracer A collection of call stats for channelz.CallTracer.Factory ChannelLoggerImpl ChannelTracer Tracks a collections of channel tracing events for a channel/subchannel.ClientCallImpl Implementation ofClientCall
.ClientCallImpl.CancellationHandler ClientCallImpl.ClientStreamProvider Provider ofClientStream
s.ClientStream Extension ofStream
to support client-side termination semantics.ClientStreamListener An observer of client-side stream events.ClientStreamListener.RpcProgress The progress of the RPC when client stream listener is closed.ClientTransport The client-side transport typically encapsulating a single connection to a remote server.ClientTransport.PingCallback A callback that is invoked when the acknowledgement to aClientTransport.ping(io.grpc.internal.ClientTransport.PingCallback, java.util.concurrent.Executor)
is received.ClientTransportFactory Pre-configured factory for creatingConnectionClientTransport
instances.ClientTransportFactory.ClientTransportOptions ClientTransportFactory.SwapChannelCredentialsResult CompositeReadableBuffer AReadableBuffer
that is composed of 0 or moreReadableBuffer
s.CompositeReadableBuffer.NoThrowReadOperation CompositeReadableBuffer.ReadOperation A simple read operation to perform on a singleReadableBuffer
.ConnectionClientTransport AManagedClientTransport
that is based on a connection.ConnectivityStateManager Manages connectivity states of the channel.ConnectivityStateManager.Listener ContextRunnable Utility base implementation ofRunnable
that performs the same function asContext.wrap(Runnable)
without requiring the construction of an additional object.Deframer Interface for deframing gRPC messages.DelayedClientCall A call that queues requests before a real call is ready to be delegated to.DelayedClientCall.DelayedListener DelayedClientTransport A client transport that queues requests before a real transport is available.DelayedClientTransport.PendingStream DelayedClientTransport.PickerState DelayedStream A stream that queues requests before the transport is available, and delegates to a real stream implementation when the transport is available.DelayedStream.DelayedStreamListener DnsNameResolver.AddressResolver AddressResolver resolves a hostname into a list of addresses.DnsNameResolver.InternalResolutionResult Used as a DNS-based name resolver's internal representation of resolution result.DnsNameResolver.JdkAddressResolver DnsNameResolver.ResourceResolver DnsNameResolver.ResourceResolver
is a Dns ResourceRecord resolver.DnsNameResolver.ResourceResolverFactory DnsNameResolver.ResourceResolverFactory
is a factory for making resource resolvers.DnsNameResolver.SrvRecord Describes a parsed SRV record.ExponentialBackoffPolicy Retry Policy for Transport reconnection.FailingClientTransport A client transport that creates streams that will immediately fail when started.ForwardingConnectionClientTransport ForwardingDeframerListener Forwards listener callbacks to a delegate.ForwardingManagedChannel ForwardingNameResolver A forwarding class to ensure non overridden methods are forwarded to the delegate.Framer Interface for framing gRPC messages.GrpcUtil.GrpcBuildVersion GrpcUtil.Http2Error All error codes identified by the HTTP/2 spec.GzipInflatingBuffer Processes gzip streams, delegating toInflater
to perform on-demand inflation of the deflated blocks.GzipInflatingBuffer.GzipMetadataReader Reads gzip header and trailer bytes from the inflater's buffer (if bytes beyond the inflate block were given to the inflater) and then fromgzippedData
, and handles updating the CRC and the count of gzipped bytes consumed.GzipInflatingBuffer.State HedgingPolicy Hedging policy data object.InsightBuilder Builds a concise and readable string that gives insight of the concerned part of the system.InternalHandlerRegistry InternalHandlerRegistry.Builder InternalServer An object that accepts new incoming connections on one or more listening socket addresses.InternalSubchannel Transports for a singleSocketAddress
.InternalSubchannel.Callback InternalSubchannel.Index Index as in 'i', the pointer to an entry.InUseStateAggregator Aggregates the in-use state of a set of objects.JndiResourceResolverFactory.RecordFetcher KeepAliveEnforcer.SystemTicker KeepAliveEnforcer.Ticker KeepAliveManager.KeepAlivePinger KeepAliveManager.State LongCounter An interface for a long base counter.ManagedChannelImpl A communication channel for making outgoing RPCs.ManagedChannelImpl.ChannelStreamProvider ManagedChannelImpl.ExecutorHolder Lazily request for Executor from an executor pool.ManagedChannelImpl.LbHelperImpl ManagedChannelImpl.RealChannel ManagedChannelImpl.RealChannel.PendingCall ManagedChannelImpl.ResolutionState A ResolutionState indicates the status of last name resolution.ManagedChannelImpl.RestrictedScheduledExecutor ManagedChannelImpl.UncommittedRetriableStreamsRegistry A registry that prevents channel shutdown from killing existing retry attempts that are in backoff.ManagedChannelImplBuilder Default managed channel builder, for usage in Transport implementations.ManagedChannelImplBuilder.ChannelBuilderDefaultPortProvider An interface for Transport implementors to provide a default port toNameResolver
for use in cases where the target string doesn't include a port.ManagedChannelImplBuilder.ClientTransportFactoryBuilder An interface for Transport implementors to provide theClientTransportFactory
appropriate for the channel.ManagedChannelImplBuilder.ResolvedNameResolver ManagedChannelOrphanWrapper Best effort detecting channels that has not been properly cleaned up.ManagedChannelOrphanWrapper.ManagedChannelReference ManagedChannelServiceConfig ManagedChannelServiceConfig
is a fully parsed and validated representation of service configuration data.ManagedChannelServiceConfig.MethodInfo Equivalent of MethodConfig from a ServiceConfig with restrictions from Channel setting.ManagedClientTransport AClientTransport
that has life-cycle management.ManagedClientTransport.Listener Receives notifications for the transport life-cycle events.MaxConnectionIdleManager.Ticker MessageDeframer Deframer for GRPC frames.MessageDeframer.Listener A listener of deframing events.MessageDeframer.State MessageFramer Encodes gRPC messages to be delivered via the transport layer which implementsMessageFramer.Sink
.MessageFramer.BufferChainOutputStream Produce a collection ofWritableBuffer
instances from the data written to anOutputStream
.MessageFramer.OutputStreamAdapter OutputStream whose write()s are passed to the framer.MessageFramer.Sink Sink implemented by the transport layer to receive frames and forward them to their destination.MetadataApplierImpl.MetadataApplierListener MigratingThreadDeframer.DeframeMessageProducer MigratingThreadDeframer.MigratingDeframerListener MigratingThreadDeframer.Op NoopClientStream An implementation ofClientStream
that silently does nothing for the operations.ObjectPool An object pool.OobChannel A ManagedChannel backed by a singleInternalSubchannel
and used forLoadBalancer
to its own RPC needs.PickFirstLeafLoadBalancer ALoadBalancer
that provides no load-balancing over the addresses from theNameResolver
.PickFirstLeafLoadBalancer.Index Index as in 'i', the pointer to an entry.PickFirstLeafLoadBalancer.SubchannelData ProxyDetectorImpl.AuthenticationProvider This interface makes unit testing easier by avoiding direct calls to static methods.ReadableBuffer Interface for an abstract byte buffer.ReadableBuffers.ByteArrayWrapper AReadableBuffer
that is backed by a byte array.ReadableBuffers.ByteReadableBufferWrapper AReadableBuffer
that is backed by aByteBuffer
.Rescheduler Reschedules a runnable lazily.RetriableStream A logicalClientStream
that is retriable.RetriableStream.BufferEntry RetriableStream.ChannelBufferMeter Used to keep track of the total amount of memory used to buffer retryable or hedged RPCs for the Channel.RetriableStream.FutureCanceller Allows cancelling a Future without racing with setting the future.RetriableStream.HedgingPlan RetriableStream.RetryPlan RetriableStream.SavedCloseMasterListenerReason RetriableStream.State RetriableStream.Substream A wrapper of a physical stream of a retry/hedging attempt, that comes with some useful attributes.RetriableStream.Throttle Used for retry throttling.RetryingNameResolver.ResolutionResultListener Simple callback class to store inNameResolver.ResolutionResult
attributes so that ManagedChannel can indicate if the resolved addresses were accepted.RetryPolicy Retry policy data object.RetryScheduler This interface is used to schedule future retry attempts for a failed operation.SerializingExecutor Executor ensuring that allRunnable
tasks submitted are executed in order using the providedExecutor
, and serially such that no two will ever be running at the same time.SerializingExecutor.AtomicHelper ServerCallImpl ServerImpl Default implementation ofServer
, for creation by transports.ServerImpl.ServerTransportListenerImpl.ServerCallParameters ServerImplBuilder Default builder forServer
instances, for usage in Transport implementations.ServerImplBuilder.ClientTransportServersBuilder An interface to provide to provide transport specific information for the server.ServerListener A listener to a server for transport creation events.ServerStream Extension ofStream
to support server-side termination semantics.ServerStreamListener An observer of server-side stream events.ServerTransport An inbound connection.ServerTransportListener A observer of a server-side transport for stream creation events.ServiceConfigUtil.LbConfig A LoadBalancingConfig that includes the policy name (the key) and its raw config value (parsed JSON).SharedResourceHolder A holder for shared resource singletons.SharedResourceHolder.Instance SharedResourceHolder.Resource Defines a resource, and the way to create and destroy instances of it.SharedResourceHolder.ScheduledExecutorFactory SharedResourcePool An ObjectPool backed by aSharedResourceHolder.Resource
.SpiffeUtil.SpiffeBundle Represents a SPIFFE trust bundle; that is, a map from trust domain to set of trusted certificates.SpiffeUtil.SpiffeId Represents a SPIFFE ID as defined in the SPIFFE standard.StatsTraceContext The stats and tracing information for a stream.Stream A single stream of communication between two end-points within a transport.StreamListener An observer ofStream
events.StreamListener.MessageProducer A producer for deframed gRPC messages.ThreadOptimizedDeframer ADeframer
that optimizations by taking over part of the thread safety.TimeProvider Time source representing the current system time in nanos.TransportProvider Provides transports for sending RPCs.TransportTracer A class for gathering statistics about a transport.TransportTracer.Factory TransportTracer.FlowControlReader An interface for reading the local and remote flow control windows of the transport.TransportTracer.FlowControlWindows A container that holds the local and remote flow control window sizes.WritableBuffer An interface for a byte buffer that can only be written to.WritableBufferAllocator An allocator of buffers provided by the transport implementation toMessageFramer
so it can send chunks of data to the transport in a form that the transport can directly serialize. -
Classes in io.grpc.internal used by io.grpc.netty Class Description AbstractClientStream The abstract base class forClientStream
implementations.AbstractClientStream.Sink A sink for outbound operations, separated from the stream simply to avoid name collisions/confusion.AbstractClientStream.TransportState This should only be called from the transport thread.AbstractReadableBuffer Abstract base class forReadableBuffer
implementations.AbstractServerStream Abstract base class forServerStream
implementations.AbstractServerStream.Sink A sink for outbound operations, separated from the stream simply to avoid name collisions/confusion.AbstractServerStream.TransportState This should only be called from the transport thread (except for private interactions withAbstractServerStream
).AbstractStream The stream and stream state as used by the application.AbstractStream.TransportState Stream state as used by the transport.ApplicationThreadDeframer.TransportExecutor ApplicationThreadDeframerListener.TransportExecutor AtomicBackoff Along
atomically updated due to errors caused by the value being too small.ClientStream Extension ofStream
to support client-side termination semantics.ClientTransport The client-side transport typically encapsulating a single connection to a remote server.ClientTransport.PingCallback A callback that is invoked when the acknowledgement to aClientTransport.ping(io.grpc.internal.ClientTransport.PingCallback, java.util.concurrent.Executor)
is received.ClientTransportFactory Pre-configured factory for creatingConnectionClientTransport
instances.ClientTransportFactory.ClientTransportOptions ClientTransportFactory.SwapChannelCredentialsResult ConnectionClientTransport AManagedClientTransport
that is based on a connection.Http2ClientStreamTransportState Base implementation for client streams using HTTP2 as the transport.Http2Ping Represents an outstanding PING operation on an HTTP/2 channel.InternalServer An object that accepts new incoming connections on one or more listening socket addresses.InUseStateAggregator Aggregates the in-use state of a set of objects.KeepAliveEnforcer Monitors the client's PING usage to make sure the rate is permitted.KeepAliveManager Manages keepalive pings.KeepAliveManager.KeepAlivePinger ManagedChannelImplBuilder Default managed channel builder, for usage in Transport implementations.ManagedChannelImplBuilder.ChannelBuilderDefaultPortProvider An interface for Transport implementors to provide a default port toNameResolver
for use in cases where the target string doesn't include a port.ManagedChannelImplBuilder.ClientTransportFactoryBuilder An interface for Transport implementors to provide theClientTransportFactory
appropriate for the channel.ManagedClientTransport AClientTransport
that has life-cycle management.ManagedClientTransport.Listener Receives notifications for the transport life-cycle events.MaxConnectionIdleManager Monitors connection idle time; shutdowns the connection if the max connection idle is reached.MessageDeframer.Listener A listener of deframing events.MessageFramer.Sink Sink implemented by the transport layer to receive frames and forward them to their destination.ObjectPool An object pool.ReadableBuffer Interface for an abstract byte buffer.ServerImplBuilder Default builder forServer
instances, for usage in Transport implementations.ServerImplBuilder.ClientTransportServersBuilder An interface to provide to provide transport specific information for the server.ServerListener A listener to a server for transport creation events.ServerStream Extension ofStream
to support server-side termination semantics.ServerTransport An inbound connection.ServerTransportListener A observer of a server-side transport for stream creation events.SharedResourceHolder.Resource Defines a resource, and the way to create and destroy instances of it.StatsTraceContext The stats and tracing information for a stream.Stream A single stream of communication between two end-points within a transport.TransportTracer A class for gathering statistics about a transport.TransportTracer.Factory TransportTracer.FlowControlReader An interface for reading the local and remote flow control windows of the transport.TransportTracer.FlowControlWindows A container that holds the local and remote flow control window sizes.WritableBuffer An interface for a byte buffer that can only be written to.WritableBufferAllocator An allocator of buffers provided by the transport implementation toMessageFramer
so it can send chunks of data to the transport in a form that the transport can directly serialize. -
Classes in io.grpc.internal used by io.grpc.protobuf.services Class Description BackoffPolicy Determines how long to wait before doing some action (typically a retry, or a reconnect).BackoffPolicy.Provider -
Classes in io.grpc.internal used by io.grpc.rls Class Description BackoffPolicy Determines how long to wait before doing some action (typically a retry, or a reconnect).BackoffPolicy.Provider ObjectPool An object pool. -
Classes in io.grpc.internal used by io.grpc.servlet Class Description AbstractServerStream Abstract base class forServerStream
implementations.AbstractServerStream.Sink A sink for outbound operations, separated from the stream simply to avoid name collisions/confusion.AbstractServerStream.TransportState This should only be called from the transport thread (except for private interactions withAbstractServerStream
).AbstractStream The stream and stream state as used by the application.AbstractStream.TransportState Stream state as used by the transport.ApplicationThreadDeframer.TransportExecutor ApplicationThreadDeframerListener.TransportExecutor InternalServer An object that accepts new incoming connections on one or more listening socket addresses.MessageDeframer.Listener A listener of deframing events.MessageFramer.Sink Sink implemented by the transport layer to receive frames and forward them to their destination.SerializingExecutor Executor ensuring that allRunnable
tasks submitted are executed in order using the providedExecutor
, and serially such that no two will ever be running at the same time.ServerImplBuilder Default builder forServer
instances, for usage in Transport implementations.ServerListener A listener to a server for transport creation events.ServerStream Extension ofStream
to support server-side termination semantics.ServerTransport An inbound connection.ServerTransportListener A observer of a server-side transport for stream creation events.StatsTraceContext The stats and tracing information for a stream.Stream A single stream of communication between two end-points within a transport.TransportTracer A class for gathering statistics about a transport.WritableBuffer An interface for a byte buffer that can only be written to. -
Classes in io.grpc.internal used by io.grpc.servlet.jakarta Class Description AbstractServerStream Abstract base class forServerStream
implementations.AbstractServerStream.Sink A sink for outbound operations, separated from the stream simply to avoid name collisions/confusion.AbstractServerStream.TransportState This should only be called from the transport thread (except for private interactions withAbstractServerStream
).AbstractStream The stream and stream state as used by the application.AbstractStream.TransportState Stream state as used by the transport.ApplicationThreadDeframer.TransportExecutor ApplicationThreadDeframerListener.TransportExecutor InternalServer An object that accepts new incoming connections on one or more listening socket addresses.MessageDeframer.Listener A listener of deframing events.MessageFramer.Sink Sink implemented by the transport layer to receive frames and forward them to their destination.SerializingExecutor Executor ensuring that allRunnable
tasks submitted are executed in order using the providedExecutor
, and serially such that no two will ever be running at the same time.ServerImplBuilder Default builder forServer
instances, for usage in Transport implementations.ServerListener A listener to a server for transport creation events.ServerStream Extension ofStream
to support server-side termination semantics.ServerTransport An inbound connection.ServerTransportListener A observer of a server-side transport for stream creation events.StatsTraceContext The stats and tracing information for a stream.Stream A single stream of communication between two end-points within a transport.TransportTracer A class for gathering statistics about a transport.WritableBuffer An interface for a byte buffer that can only be written to. -
Classes in io.grpc.internal used by io.grpc.util Class Description SerializingExecutor Executor ensuring that allRunnable
tasks submitted are executed in order using the providedExecutor
, and serially such that no two will ever be running at the same time.TimeProvider Time source representing the current system time in nanos.