Skip navigation links
A B C D E F G H I J K L M N O P R S T U V W 

A

AbstractClientStream - Class in io.grpc.internal
The abstract base class for ClientStream implementations.
AbstractClientStream(WritableBufferAllocator, StatsTraceContext, TransportTracer, Metadata, CallOptions, boolean) - Constructor for class io.grpc.internal.AbstractClientStream
 
AbstractClientStream.Sink - Interface in io.grpc.internal
A sink for outbound operations, separated from the stream simply to avoid name collisions/confusion.
AbstractClientStream.TransportState - Class in io.grpc.internal
This should only called from the transport thread.
abstractClientStreamSink() - Method in class io.grpc.internal.AbstractClientStream
Sink for transport to be called to perform outbound operations.
AbstractManagedChannelImplBuilder<T extends AbstractManagedChannelImplBuilder<T>> - Class in io.grpc.internal
The base class for channel builders.
AbstractManagedChannelImplBuilder(String) - Constructor for class io.grpc.internal.AbstractManagedChannelImplBuilder
 
AbstractManagedChannelImplBuilder(SocketAddress, String) - Constructor for class io.grpc.internal.AbstractManagedChannelImplBuilder
 
AbstractReadableBuffer - Class in io.grpc.internal
Abstract base class for ReadableBuffer implementations.
AbstractReadableBuffer() - Constructor for class io.grpc.internal.AbstractReadableBuffer
 
AbstractServerImplBuilder<T extends AbstractServerImplBuilder<T>> - Class in io.grpc.internal
The base class for server builders.
AbstractServerImplBuilder() - Constructor for class io.grpc.internal.AbstractServerImplBuilder
 
AbstractServerStream - Class in io.grpc.internal
Abstract base class for ServerStream implementations.
AbstractServerStream(WritableBufferAllocator, StatsTraceContext) - Constructor for class io.grpc.internal.AbstractServerStream
 
AbstractServerStream.Sink - Interface in io.grpc.internal
A sink for outbound operations, separated from the stream simply to avoid name collisions/confusion.
AbstractServerStream.TransportState - Class in io.grpc.internal
This should only called from the transport thread (except for private interactions with AbstractServerStream).
abstractServerStreamSink() - Method in class io.grpc.internal.AbstractServerStream
Sink for transport to be called to perform outbound operations.
AbstractStream - Class in io.grpc.internal
The stream and stream state as used by the application.
AbstractStream() - Constructor for class io.grpc.internal.AbstractStream
 
AbstractStream.TransportState - Class in io.grpc.internal
Stream state as used by the transport.
ACCEPT_ENCODING_SPLITTER - Static variable in class io.grpc.internal.GrpcUtil
 
add(long) - Method in interface io.grpc.internal.LongCounter
Adds the delta to this counter.
add(long) - Method in class io.grpc.internal.ReflectionLongAdderCounter
 
addBuffer(ReadableBuffer) - Method in class io.grpc.internal.CompositeReadableBuffer
Adds a new ReadableBuffer at the end of the buffer list.
addCallback(ClientTransport.PingCallback, Executor) - Method in class io.grpc.internal.Http2Ping
Registers a callback that is invoked when the ping operation completes.
addService(ServerServiceDefinition) - Method in class io.grpc.internal.AbstractServerImplBuilder
 
addService(BindableService) - Method in class io.grpc.internal.AbstractServerImplBuilder
 
addService(ServerServiceDefinition) - Method in class io.grpc.util.MutableHandlerRegistry
Registers a service.
addService(BindableService) - Method in class io.grpc.util.MutableHandlerRegistry
Registers a service.
addStreamTracerFactory(ServerStreamTracer.Factory) - Method in class io.grpc.internal.AbstractServerImplBuilder
 
addTransportFilter(ServerTransportFilter) - Method in class io.grpc.internal.AbstractServerImplBuilder
 
allocate(int) - Method in interface io.grpc.internal.WritableBufferAllocator
Request a new WritableBuffer with the given capacityHint.
append(Object) - Method in class io.grpc.internal.InsightBuilder
Appends a piece of information which is a plain string.
appendKeyValue(String, Object) - Method in class io.grpc.internal.InsightBuilder
Appends a piece of information which is a key-value , which will be formatted into "key=value".
appendTimeoutInsight(InsightBuilder) - Method in class io.grpc.internal.AbstractClientStream
 
appendTimeoutInsight(InsightBuilder) - Method in interface io.grpc.internal.ClientStream
Append information that will be included in the locally generated DEADLINE_EXCEEDED errors to the given InsightBuilder, in order to tell the user about the state of the stream so that they can better diagnose the cause of the error.
appendTimeoutInsight(InsightBuilder) - Method in class io.grpc.internal.FailingClientStream
 
appendTimeoutInsight(InsightBuilder) - Method in class io.grpc.internal.NoopClientStream
 
ApplicationThreadDeframer - Class in io.grpc.internal
Sits between AbstractStream.TransportState and MessageDeframer to deframe in the client thread.
array() - Method in class io.grpc.internal.AbstractReadableBuffer
 
array() - Method in class io.grpc.internal.ForwardingReadableBuffer
 
array() - Method in interface io.grpc.internal.ReadableBuffer
Gets the backing array for this buffer.
arrayOffset() - Method in class io.grpc.internal.AbstractReadableBuffer
 
arrayOffset() - Method in class io.grpc.internal.ForwardingReadableBuffer
 
arrayOffset() - Method in interface io.grpc.internal.ReadableBuffer
Gets the offset in the backing array of the current read position.
asChannel() - Method in class io.grpc.util.ForwardingSubchannel
 
AtomicBackoff - Class in io.grpc.internal
A long atomically updated due to errors caused by the value being too small.
AtomicBackoff(String, long) - Constructor for class io.grpc.internal.AtomicBackoff
Construct an atomic with initial value value.
AtomicBackoff.State - Class in io.grpc.internal
 
ATTR_CLIENT_EAG_ATTRS - Static variable in class io.grpc.internal.GrpcAttributes
Attribute key for the attributes of the EquivalentAddressGroup (EquivalentAddressGroup.getAttributes()) that the transport's server address is from.
ATTR_LB_ADDR_AUTHORITY - Static variable in class io.grpc.internal.GrpcAttributes
The naming authority of a gRPC LB server address.
ATTR_LB_PROVIDED_BACKEND - Static variable in class io.grpc.internal.GrpcAttributes
Whether this EquivalentAddressGroup was provided by a GRPCLB server.
ATTR_SECURITY_LEVEL - Static variable in class io.grpc.internal.GrpcAttributes
The security level of the transport.
authorityFromHostAndPort(String, int) - Static method in class io.grpc.internal.GrpcUtil
Combine a host and port into an authority string.
authorityToUri(String) - Static method in class io.grpc.internal.GrpcUtil
Parse an authority into a URI for retrieving the host and port.
AutoConfiguredLoadBalancerFactory - Class in io.grpc.internal
 
AutoConfiguredLoadBalancerFactory(String) - Constructor for class io.grpc.internal.AutoConfiguredLoadBalancerFactory
 
AutoConfiguredLoadBalancerFactory.AutoConfiguredLoadBalancer - Class in io.grpc.internal
 
awaitTermination(long, TimeUnit) - Method in class io.grpc.internal.ServerImpl
 
awaitTermination() - Method in class io.grpc.internal.ServerImpl
 

B

backoff() - Method in class io.grpc.internal.AtomicBackoff.State
Causes future invocations of AtomicBackoff.getState() to have a value at least double this state's value.
BackoffPolicy - Interface in io.grpc.internal
Determines how long to wait before doing some action (typically a retry, or a reconnect).
BackoffPolicy.Provider - Interface in io.grpc.internal
 
build() - Method in class io.grpc.internal.AbstractManagedChannelImplBuilder
 
build() - Method in class io.grpc.internal.AbstractServerImplBuilder
 
buildTransportFactory() - Method in class io.grpc.inprocess.InProcessChannelBuilder
 
buildTransportFactory() - Method in class io.grpc.internal.AbstractManagedChannelImplBuilder
Subclasses should override this method to provide the ClientTransportFactory appropriate for this channel.
buildTransportServers(List<? extends ServerStreamTracer.Factory>) - Method in class io.grpc.inprocess.InProcessServerBuilder
 
buildTransportServers(List<? extends ServerStreamTracer.Factory>) - Method in class io.grpc.internal.AbstractServerImplBuilder
Children of AbstractServerBuilder should override this method to provide transport specific information for the server.
bytesRead(int) - Method in class io.grpc.internal.ApplicationThreadDeframer
 
bytesRead(int) - Method in interface io.grpc.internal.MessageDeframer.Listener
Called when the given number of bytes has been read from the input source of the deframer.

C

CALL_OPTIONS_RPC_OWNED_BY_BALANCER - Static variable in class io.grpc.internal.GrpcUtil
RPCs created on the Channel returned by LoadBalancer.Subchannel.asChannel() will have this option with value true.
cancel(Status) - Method in class io.grpc.internal.AbstractClientStream
 
cancel(Status) - Method in interface io.grpc.internal.AbstractClientStream.Sink
Tears down the stream, typically in the event of a timeout.
cancel(Status) - Method in class io.grpc.internal.AbstractServerStream
 
cancel(Status) - Method in interface io.grpc.internal.AbstractServerStream.Sink
Tears down the stream, typically in the event of a timeout.
cancel(Status) - Method in interface io.grpc.internal.ClientStream
Abnormally terminates the stream.
cancel(Status) - Method in class io.grpc.internal.NoopClientStream
 
cancel(Status) - Method in interface io.grpc.internal.ServerStream
Tears down the stream, typically in the event of a timeout.
canHandleEmptyAddressListFromNameResolution() - Method in class io.grpc.util.ForwardingLoadBalancer
 
CensusStatsModule - Class in io.grpc.internal
Provides factories for StreamTracer that records stats to Census.
CensusStatsModule(Tagger, TagContextBinarySerializer, StatsRecorder, Supplier<Stopwatch>, boolean, boolean, boolean, boolean) - Constructor for class io.grpc.internal.CensusStatsModule
Creates a CensusStatsModule with the given OpenCensus implementation.
checkAuthority(String) - Method in class io.grpc.internal.AbstractManagedChannelImplBuilder
Verifies the authority is valid.
checkAuthority(String) - Static method in class io.grpc.internal.GrpcUtil
Verify authority is valid for use with gRPC.
checkReadable(int) - Method in class io.grpc.internal.AbstractReadableBuffer
 
clampKeepAliveTimeInNanos(long) - Static method in class io.grpc.internal.KeepAliveManager
Bumps keepalive time to 10 seconds if the specified value was smaller than that.
clampKeepAliveTimeoutInNanos(long) - Static method in class io.grpc.internal.KeepAliveManager
Bumps keepalive timeout to 10 milliseconds if the specified value was smaller than that.
clientInboundHeaders() - Method in class io.grpc.internal.StatsTraceContext
clientInboundTrailers(Metadata) - Method in class io.grpc.internal.StatsTraceContext
ClientKeepAlivePinger(ConnectionClientTransport) - Constructor for class io.grpc.internal.KeepAliveManager.ClientKeepAlivePinger
 
clientOutboundHeaders() - Method in class io.grpc.internal.StatsTraceContext
ClientStream - Interface in io.grpc.internal
Extension of Stream to support client-side termination semantics.
ClientStreamListener - Interface in io.grpc.internal
An observer of client-side stream events.
ClientStreamListener.RpcProgress - Enum in io.grpc.internal
The progress of the RPC when client stream listener is closed.
ClientTransport - Interface in io.grpc.internal
The client-side transport typically encapsulating a single connection to a remote server.
ClientTransport.PingCallback - Interface in io.grpc.internal
A callback that is invoked when the acknowledgement to a ClientTransport.ping(io.grpc.internal.ClientTransport.PingCallback, java.util.concurrent.Executor) is received.
ClientTransportFactory - Interface in io.grpc.internal
Pre-configured factory for creating ConnectionClientTransport instances.
ClientTransportFactory.ClientTransportOptions - Class in io.grpc.internal
Options passed to #newClientTransport(SocketAddress, ClientTransportOptions).
ClientTransportOptions() - Constructor for class io.grpc.internal.ClientTransportFactory.ClientTransportOptions
 
close() - Method in class io.grpc.internal.AbstractReadableBuffer
 
close(Status, Metadata) - Method in class io.grpc.internal.AbstractServerStream
 
close() - Method in class io.grpc.internal.ApplicationThreadDeframer
 
close() - Method in interface io.grpc.internal.ClientTransportFactory
Releases any resources.
close() - Method in class io.grpc.internal.CompositeReadableBuffer
 
close() - Method in interface io.grpc.internal.Deframer
Closes this deframer and frees any resources.
close() - Method in class io.grpc.internal.ForwardingReadableBuffer
 
close() - Method in interface io.grpc.internal.Framer
Closes, with flush.
close() - Method in class io.grpc.internal.MessageDeframer
 
close() - Method in class io.grpc.internal.MessageFramer
Flushes and closes the framer and releases any buffers.
close() - Method in interface io.grpc.internal.ReadableBuffer
Closes this buffer and releases any resources.
close(Status, Metadata) - Method in interface io.grpc.internal.ServerStream
Closes the stream for both reading and writing.
close(T) - Method in interface io.grpc.internal.SharedResourceHolder.Resource
Destroy the given instance.
closed(Status, Metadata) - Method in interface io.grpc.internal.ClientStreamListener
Called when the stream is fully closed.
closed(Status, ClientStreamListener.RpcProgress, Metadata) - Method in interface io.grpc.internal.ClientStreamListener
Called when the stream is fully closed.
closed(Status) - Method in interface io.grpc.internal.ServerStreamListener
Called when the stream is fully closed.
closeDeframer(boolean) - Method in class io.grpc.internal.AbstractStream.TransportState
Closes the deframer and frees any resources.
closeQuietly(InputStream) - Static method in class io.grpc.internal.GrpcUtil
Closes an InputStream, ignoring IOExceptions.
closeWhenComplete() - Method in class io.grpc.internal.ApplicationThreadDeframer
 
closeWhenComplete() - Method in interface io.grpc.internal.Deframer
Close when any messages currently queued have been requested and delivered.
closeWhenComplete() - Method in class io.grpc.internal.MessageDeframer
 
code() - Method in enum io.grpc.internal.GrpcUtil.Http2Error
Gets the code for this error used on the wire.
complete() - Method in class io.grpc.internal.AbstractServerStream.TransportState
Indicates the stream is considered completely closed and there is no further opportunity for error.
complete() - Method in class io.grpc.internal.Http2Ping
Completes this operation successfully.
CompositeReadableBuffer - Class in io.grpc.internal
A ReadableBuffer that is composed of 0 or more ReadableBuffers.
CompositeReadableBuffer() - Constructor for class io.grpc.internal.CompositeReadableBuffer
 
compressorRegistry(CompressorRegistry) - Method in class io.grpc.internal.AbstractManagedChannelImplBuilder
 
compressorRegistry(CompressorRegistry) - Method in class io.grpc.internal.AbstractServerImplBuilder
 
ConnectionClientTransport - Interface in io.grpc.internal
A ManagedClientTransport that is based on a connection.
CONTENT_ACCEPT_ENCODING - Static variable in class io.grpc.internal.GrpcUtil
The accepted content-encodings that can be used to compress the full gRPC stream.
CONTENT_ACCEPT_ENCODING_KEY - Static variable in class io.grpc.internal.GrpcUtil
Metadata.Key for the stream's accepted content encoding header.
CONTENT_ENCODING - Static variable in class io.grpc.internal.GrpcUtil
The content-encoding used to compress the full gRPC stream.
CONTENT_ENCODING_KEY - Static variable in class io.grpc.internal.GrpcUtil
Metadata.Key for the stream's content encoding header.
CONTENT_TYPE_GRPC - Static variable in class io.grpc.internal.GrpcUtil
Content-Type used for GRPC-over-HTTP/2.
CONTENT_TYPE_KEY - Static variable in class io.grpc.internal.GrpcUtil
Metadata.Key for the Content-Type request/response header.
create() - Method in interface io.grpc.internal.SharedResourceHolder.Resource
Create a new instance of the resource.
create() - Method in class io.grpc.internal.TransportTracer.Factory
 
createOobChannel(EquivalentAddressGroup, String) - Method in class io.grpc.util.ForwardingLoadBalancerHelper
 
createResolvingOobChannel(String) - Method in class io.grpc.util.ForwardingLoadBalancerHelper
 
createSubchannel(List<EquivalentAddressGroup>, Attributes) - Method in class io.grpc.util.ForwardingLoadBalancerHelper
Deprecated.
createSubchannel(LoadBalancer.CreateSubchannelArgs) - Method in class io.grpc.util.ForwardingLoadBalancerHelper
 
currentTimeNanos() - Method in interface io.grpc.internal.TimeProvider
Returns the current nano time.

D

decompressorRegistry(DecompressorRegistry) - Method in class io.grpc.internal.AbstractManagedChannelImplBuilder
 
decompressorRegistry(DecompressorRegistry) - Method in class io.grpc.internal.AbstractServerImplBuilder
 
DEFAULT_KEEPALIVE_TIMEOUT_NANOS - Static variable in class io.grpc.internal.GrpcUtil
The default timeout in nanos for a keepalive ping request.
DEFAULT_LB_POLICY - Static variable in class io.grpc.internal.GrpcUtil
The very default load-balancing policy.
DEFAULT_MAX_HEADER_LIST_SIZE - Static variable in class io.grpc.internal.GrpcUtil
The default maximum size (in bytes) for inbound header/trailer.
DEFAULT_MAX_MESSAGE_SIZE - Static variable in class io.grpc.internal.GrpcUtil
The default maximum uncompressed size (in bytes) for inbound messages.
DEFAULT_ONREADY_THRESHOLD - Static variable in class io.grpc.internal.AbstractStream.TransportState
The default number of queued bytes for a given stream, below which StreamListener.onReady() will be called.
DEFAULT_PORT_PLAINTEXT - Static variable in class io.grpc.internal.GrpcUtil
The default port for plain-text connections.
DEFAULT_PORT_SSL - Static variable in class io.grpc.internal.GrpcUtil
The default port for SSL connections.
DEFAULT_PROXY_DETECTOR - Static variable in class io.grpc.internal.GrpcUtil
The default proxy detector.
DEFAULT_SERVER_KEEPALIVE_TIME_NANOS - Static variable in class io.grpc.internal.GrpcUtil
The default delay in nanos for server keepalive.
DEFAULT_SERVER_KEEPALIVE_TIMEOUT_NANOS - Static variable in class io.grpc.internal.GrpcUtil
The default timeout in nanos for a server keepalive ping request.
defaultLoadBalancingPolicy(String) - Method in class io.grpc.internal.AbstractManagedChannelImplBuilder
 
defaultServiceConfig(Map<String, ?>) - Method in class io.grpc.internal.AbstractManagedChannelImplBuilder
 
deframe(ReadableBuffer) - Method in class io.grpc.internal.AbstractStream.TransportState
Called to parse a received frame and attempt delivery of any completed messages.
deframe(ReadableBuffer) - Method in class io.grpc.internal.ApplicationThreadDeframer
 
deframe(ReadableBuffer) - Method in interface io.grpc.internal.Deframer
Adds the given data to this deframer and attempts delivery to the listener.
deframe(ReadableBuffer) - Method in class io.grpc.internal.MessageDeframer
 
deframeFailed(Throwable) - Method in class io.grpc.internal.ApplicationThreadDeframer
 
deframeFailed(Throwable) - Method in interface io.grpc.internal.MessageDeframer.Listener
Called when a MessageDeframer.deframe(ReadableBuffer) operation failed.
Deframer - Interface in io.grpc.internal
Interface for deframing gRPC messages.
deframerClosed(boolean) - Method in class io.grpc.internal.AbstractClientStream.TransportState
 
deframerClosed(boolean) - Method in class io.grpc.internal.AbstractServerStream.TransportState
 
deframerClosed(boolean) - Method in class io.grpc.internal.ApplicationThreadDeframer
 
deframerClosed(boolean) - Method in interface io.grpc.internal.MessageDeframer.Listener
Called when the deframer closes.
delegate() - Method in class io.grpc.util.ForwardingClientStreamTracer
Returns the underlying ClientStreamTracer.
delegate() - Method in class io.grpc.util.ForwardingLoadBalancer
Returns the underlying balancer.
delegate() - Method in class io.grpc.util.ForwardingLoadBalancerHelper
Returns the underlying helper.
delegate() - Method in class io.grpc.util.ForwardingSubchannel
Returns the underlying Subchannel.
delegate() - Method in class io.grpc.util.GracefulSwitchLoadBalancer
 
deliverFrame(WritableBuffer, boolean, boolean, int) - Method in class io.grpc.internal.AbstractClientStream
 
deliverFrame(WritableBuffer, boolean, boolean, int) - Method in class io.grpc.internal.AbstractServerStream
 
deliverFrame(WritableBuffer, boolean, boolean, int) - Method in interface io.grpc.internal.MessageFramer.Sink
Delivers a frame via the transport.
DeprecatedCensusConstants - Class in io.grpc.internal
Holder class for the deprecated OpenCensus constants.
directExecutor() - Method in class io.grpc.internal.AbstractManagedChannelImplBuilder
 
directExecutor() - Method in class io.grpc.internal.AbstractServerImplBuilder
 
disableRetry() - Method in class io.grpc.internal.AbstractManagedChannelImplBuilder
 
disableServiceConfigLookUp() - Method in class io.grpc.internal.AbstractManagedChannelImplBuilder
 
dispose() - Method in interface io.grpc.internal.Framer
Closes, without flush.
dispose() - Method in class io.grpc.internal.MessageFramer
Closes the framer and releases any buffers, but does not flush.
DnsNameResolverProvider - Class in io.grpc.internal
A provider for DnsNameResolver.
DnsNameResolverProvider() - Constructor for class io.grpc.internal.DnsNameResolverProvider
 

E

empty() - Static method in class io.grpc.internal.ReadableBuffers
Returns an empty ReadableBuffer instance.
enableFullStreamDecompression() - Method in class io.grpc.internal.AbstractManagedChannelImplBuilder
 
enableRetry() - Method in class io.grpc.internal.AbstractManagedChannelImplBuilder
 
endOfMessages() - Method in class io.grpc.internal.AbstractStream
Closes the underlying framer.
equals(Object) - Method in class io.grpc.inprocess.InProcessSocketAddress
 
equals(Object) - Method in class io.grpc.internal.ClientTransportFactory.ClientTransportOptions
 
equals(Object) - Method in class io.grpc.internal.ServiceConfigUtil.LbConfig
 
execute(Runnable) - Method in class io.grpc.internal.SerializingExecutor
Runs the given runnable strictly after all Runnables that were submitted before it, and using the executor passed to the constructor.
executor(Executor) - Method in class io.grpc.internal.AbstractManagedChannelImplBuilder
 
executor(Executor) - Method in class io.grpc.internal.AbstractServerImplBuilder
 
ExponentialBackoffPolicy - Class in io.grpc.internal
Retry Policy for Transport reconnection.
ExponentialBackoffPolicy() - Constructor for class io.grpc.internal.ExponentialBackoffPolicy
 
ExponentialBackoffPolicy.Provider - Class in io.grpc.internal
 

F

Factory(TimeProvider) - Constructor for class io.grpc.internal.TransportTracer.Factory
 
failed(Throwable) - Method in class io.grpc.internal.Http2Ping
Completes this operation exceptionally.
FailingClientStream - Class in io.grpc.internal
An implementation of ClientStream that fails (by calling ClientStreamListener.closed(io.grpc.Status, io.grpc.Metadata)) when started, and silently does nothing for the other operations.
FailingClientStream(Status) - Constructor for class io.grpc.internal.FailingClientStream
Creates a FailingClientStream that would fail with the given error.
FailingClientStream(Status, ClientStreamListener.RpcProgress) - Constructor for class io.grpc.internal.FailingClientStream
Creates a FailingClientStream that would fail with the given error.
fallbackHandlerRegistry(HandlerRegistry) - Method in class io.grpc.internal.AbstractServerImplBuilder
 
FixedObjectPool<T> - Class in io.grpc.internal
An object pool that always returns the same instance and does nothing when returning the object.
FixedObjectPool(T) - Constructor for class io.grpc.internal.FixedObjectPool
 
FlowControlWindows(long, long) - Constructor for class io.grpc.internal.TransportTracer.FlowControlWindows
 
flush() - Method in class io.grpc.internal.AbstractStream
 
flush() - Method in interface io.grpc.internal.Framer
Flush the buffered payload.
flush() - Method in class io.grpc.internal.MessageFramer
Flushes any buffered data in the framer to the sink.
flush() - Method in class io.grpc.internal.NoopClientStream
 
flush() - Method in interface io.grpc.internal.Stream
Flushes any internally buffered messages to the remote end-point.
forAddress(String, int) - Static method in class io.grpc.inprocess.InProcessChannelBuilder
Always fails.
forAddress(String, int) - Static method in class io.grpc.internal.AbstractManagedChannelImplBuilder
 
forCode(long) - Static method in enum io.grpc.internal.GrpcUtil.Http2Error
Looks up the HTTP/2 error code enum value for the specified code.
forName(String) - Static method in class io.grpc.inprocess.InProcessChannelBuilder
Create a channel builder that will connect to the server with the given name.
forName(String) - Static method in class io.grpc.inprocess.InProcessServerBuilder
Create a server builder that will bind with the given name.
forPort(int) - Static method in class io.grpc.inprocess.InProcessServerBuilder
Always fails.
forPort(int) - Static method in class io.grpc.internal.AbstractServerImplBuilder
 
forResource(SharedResourceHolder.Resource<T>) - Static method in class io.grpc.internal.SharedResourcePool
 
forTarget(String) - Static method in class io.grpc.inprocess.InProcessChannelBuilder
Always fails.
forTarget(String) - Static method in class io.grpc.internal.AbstractManagedChannelImplBuilder
 
ForwardingClientStreamTracer - Class in io.grpc.util
 
ForwardingClientStreamTracer() - Constructor for class io.grpc.util.ForwardingClientStreamTracer
 
ForwardingLoadBalancer - Class in io.grpc.util
 
ForwardingLoadBalancer() - Constructor for class io.grpc.util.ForwardingLoadBalancer
 
ForwardingLoadBalancerHelper - Class in io.grpc.util
 
ForwardingLoadBalancerHelper() - Constructor for class io.grpc.util.ForwardingLoadBalancerHelper
 
ForwardingReadableBuffer - Class in io.grpc.internal
Base class for a wrapper around another ReadableBuffer.
ForwardingReadableBuffer(ReadableBuffer) - Constructor for class io.grpc.internal.ForwardingReadableBuffer
Constructor.
ForwardingSubchannel - Class in io.grpc.util
 
ForwardingSubchannel() - Constructor for class io.grpc.util.ForwardingSubchannel
 
framer() - Method in class io.grpc.internal.AbstractClientStream
 
framer() - Method in class io.grpc.internal.AbstractServerStream
 
framer() - Method in class io.grpc.internal.AbstractStream
The framer to use for sending messages.
Framer - Interface in io.grpc.internal
Interface for framing gRPC messages.

G

generateName() - Static method in class io.grpc.inprocess.InProcessServerBuilder
Generates a new server name that is unique each time.
get() - Method in class io.grpc.internal.AtomicBackoff.State
 
get() - Method in interface io.grpc.internal.BackoffPolicy.Provider
 
get() - Method in class io.grpc.internal.ExponentialBackoffPolicy.Provider
 
get(SharedResourceHolder.Resource<T>) - Static method in class io.grpc.internal.SharedResourceHolder
Try to get an existing instance of the given resource.
getAllAddresses() - Method in class io.grpc.util.ForwardingSubchannel
 
getAttributes() - Method in class io.grpc.internal.AbstractServerStream
 
getAttributes() - Method in interface io.grpc.internal.ClientStream
Attributes that the stream holds at the current moment.
getAttributes() - Method in interface io.grpc.internal.ConnectionClientTransport
Returns a set of attributes, which may vary depending on the state of the transport.
getAttributes() - Method in class io.grpc.internal.NoopClientStream
 
getAttributes() - Method in interface io.grpc.internal.ServerStream
Attributes describing stream.
getAttributes() - Method in class io.grpc.util.ForwardingSubchannel
 
getAuthority() - Method in class io.grpc.internal.AbstractServerStream
 
getAuthority() - Method in class io.grpc.internal.ClientTransportFactory.ClientTransportOptions
 
getAuthority() - Method in interface io.grpc.internal.ServerStream
Gets the authority this stream is addressed to.
getAuthority() - Method in class io.grpc.util.ForwardingLoadBalancerHelper
 
getBalancerNameFromXdsConfig(Map<String, ?>) - Static method in class io.grpc.internal.ServiceConfigUtil
Extracts the loadbalancer name from xds loadbalancer config.
getChannelLogger() - Method in class io.grpc.internal.ClientTransportFactory.ClientTransportOptions
 
getChannelLogger() - Method in class io.grpc.util.ForwardingLoadBalancerHelper
 
getChannelLogger() - Method in class io.grpc.util.ForwardingSubchannel
 
getChannelz() - Method in class io.grpc.internal.AbstractServerImplBuilder
 
getChildPolicyFromXdsConfig(Map<String, ?>) - Static method in class io.grpc.internal.ServiceConfigUtil
Extracts list of child policies from xds loadbalancer config.
getDefaultFactory() - Static method in class io.grpc.internal.TransportTracer
 
getDefaultPort() - Method in class io.grpc.internal.AbstractManagedChannelImplBuilder
Subclasses can override this method to provide a default port to NameResolver for use in cases where the target string doesn't include a port.
getDefaultProxyDetector() - Static method in class io.grpc.internal.GrpcUtil
Returns a proxy detector appropriate for the current environment.
getDefaultScheme() - Method in class io.grpc.internal.DnsNameResolverProvider
 
getDelegate() - Method in class io.grpc.internal.AutoConfiguredLoadBalancerFactory.AutoConfiguredLoadBalancer
 
getEagAttributes() - Method in class io.grpc.internal.ClientTransportFactory.ClientTransportOptions
 
getFallbackPolicyFromXdsConfig(Map<String, ?>) - Static method in class io.grpc.internal.ServiceConfigUtil
Extracts list of fallback policies from xds loadbalancer config.
getGrpcUserAgent(String, String) - Static method in class io.grpc.internal.GrpcUtil
Gets the User-Agent string for the gRPC transport.
getHealthCheckedServiceName(Map<String, ?>) - Static method in class io.grpc.internal.ServiceConfigUtil
Fetch the health-checked service name from service config.
getHost(InetSocketAddress) - Static method in class io.grpc.internal.GrpcUtil
Returns the host via InetSocketAddress.getHostString() if it is possible, i.e.
getHttpConnectProxiedSocketAddress() - Method in class io.grpc.internal.ClientTransportFactory.ClientTransportOptions
 
getImmutableServices() - Method in class io.grpc.internal.ServerImpl
 
getInternalSubchannel() - Method in class io.grpc.util.ForwardingSubchannel
 
getListenSocketAddress() - Method in interface io.grpc.internal.InternalServer
Returns the listening socket address.
getListenSockets() - Method in class io.grpc.internal.ServerImpl
 
getListenSocketStats() - Method in interface io.grpc.internal.InternalServer
Returns the listen socket stats of this server.
getLoadBalancingConfigsFromServiceConfig(Map<String, ?>) - Static method in class io.grpc.internal.ServiceConfigUtil
Extracts load balancing configs from a service config.
getLogId() - Method in class io.grpc.internal.ServerImpl
 
getMutableServices() - Method in class io.grpc.internal.ServerImpl
 
getName() - Method in class io.grpc.inprocess.InProcessSocketAddress
Gets the name of the inprocess channel or server.
getNameResolverArgs() - Method in class io.grpc.util.ForwardingLoadBalancerHelper
 
getNameResolverFactory() - Method in class io.grpc.util.ForwardingLoadBalancerHelper
Deprecated.
getNameResolverRegistry() - Method in class io.grpc.util.ForwardingLoadBalancerHelper
 
getObject() - Method in class io.grpc.internal.FixedObjectPool
 
getObject() - Method in interface io.grpc.internal.ObjectPool
Get an object from the pool.
getObject() - Method in class io.grpc.internal.SharedResourcePool
 
getPolicyName() - Method in class io.grpc.internal.PickFirstLoadBalancerProvider
 
getPolicyName() - Method in class io.grpc.internal.ServiceConfigUtil.LbConfig
 
getPort() - Method in class io.grpc.internal.ServerImpl
 
getPriority() - Method in class io.grpc.internal.PickFirstLoadBalancerProvider
 
getRawConfigValue() - Method in class io.grpc.internal.ServiceConfigUtil.LbConfig
 
getScheduledExecutorService() - Method in interface io.grpc.internal.ClientTransportFactory
Returns an executor for scheduling provided by the transport.
getScheduledExecutorService() - Method in interface io.grpc.internal.ServerTransport
Returns an executor for scheduling provided by the transport.
getScheduledExecutorService() - Method in class io.grpc.util.ForwardingLoadBalancerHelper
 
getServices() - Method in class io.grpc.internal.ServerImpl
 
getServices() - Method in class io.grpc.util.MutableHandlerRegistry
Note: This does not necessarily return a consistent view of the map.
getState() - Method in class io.grpc.internal.AtomicBackoff
Returns the current state.
getStats() - Method in class io.grpc.internal.ServerImpl
 
getStats() - Method in class io.grpc.internal.TransportTracer
Returns a read only set of current stats.
getStatsTraceContext() - Method in class io.grpc.internal.AbstractStream.TransportState
 
getStickinessMetadataKeyFromServiceConfig(Map<String, ?>) - Static method in class io.grpc.internal.ServiceConfigUtil
Extracts the stickiness metadata key from a service config, or null.
getSynchronizationContext() - Method in class io.grpc.util.ForwardingLoadBalancerHelper
 
getThreadFactory(String, boolean) - Static method in class io.grpc.internal.GrpcUtil
Get a ThreadFactory suitable for use in the current environment.
getTracersForTest() - Method in class io.grpc.internal.StatsTraceContext
Returns a copy of the tracer list.
getTransportTracer() - Method in class io.grpc.internal.AbstractClientStream
 
getTransportTracer() - Method in class io.grpc.internal.AbstractStream.TransportState
 
getTransportTracerFactory() - Method in class io.grpc.internal.AbstractServerImplBuilder
 
getUserAgent() - Method in class io.grpc.internal.ClientTransportFactory.ClientTransportOptions
 
GracefulSwitchLoadBalancer - Class in io.grpc.util
A load balancer that gracefully swaps to a new lb policy.
GracefulSwitchLoadBalancer(LoadBalancer.Helper) - Constructor for class io.grpc.util.GracefulSwitchLoadBalancer
 
GrpcAttributes - Class in io.grpc.internal
Special attributes that are only useful to gRPC.
GrpcUtil - Class in io.grpc.internal
Common utilities for GRPC.
GrpcUtil.Http2Error - Enum in io.grpc.internal
All error codes identified by the HTTP/2 spec.

H

halfClose() - Method in class io.grpc.internal.AbstractClientStream
 
halfClose() - Method in interface io.grpc.internal.ClientStream
Closes the local side of this stream and flushes any remaining messages.
halfClose() - Method in class io.grpc.internal.NoopClientStream
 
halfClosed() - Method in interface io.grpc.internal.ServerStreamListener
Called when the remote side of the transport gracefully closed, indicating the client had no more data to send.
handleInUse() - Method in class io.grpc.internal.InUseStateAggregator
Called when the aggregated in-use state has changed to true, which means at least one object is in use.
handleNameResolutionError(Status) - Method in class io.grpc.util.ForwardingLoadBalancer
 
handleNotInUse() - Method in class io.grpc.internal.InUseStateAggregator
Called when the aggregated in-use state has changed to false, which means no object is in use.
handleResolvedAddresses(LoadBalancer.ResolvedAddresses) - Method in class io.grpc.internal.AutoConfiguredLoadBalancerFactory.AutoConfiguredLoadBalancer
 
handleResolvedAddresses(LoadBalancer.ResolvedAddresses) - Method in class io.grpc.util.ForwardingLoadBalancer
 
handleResolvedAddressGroups(List<EquivalentAddressGroup>, Attributes) - Method in class io.grpc.util.ForwardingLoadBalancer
Deprecated.
handleSubchannelState(LoadBalancer.Subchannel, ConnectivityStateInfo) - Method in class io.grpc.util.ForwardingLoadBalancer
Deprecated.
handleSubchannelState(LoadBalancer.Subchannel, ConnectivityStateInfo) - Method in class io.grpc.util.GracefulSwitchLoadBalancer
Deprecated.
handshakeTimeout(long, TimeUnit) - Method in class io.grpc.internal.AbstractServerImplBuilder
 
hasArray() - Method in class io.grpc.internal.AbstractReadableBuffer
 
hasArray() - Method in class io.grpc.internal.ForwardingReadableBuffer
 
hasArray() - Method in interface io.grpc.internal.ReadableBuffer
Indicates whether or not this buffer exposes a backing array.
hashCode() - Method in class io.grpc.inprocess.InProcessSocketAddress
 
hashCode() - Method in class io.grpc.internal.ClientTransportFactory.ClientTransportOptions
 
hashCode() - Method in class io.grpc.internal.ServiceConfigUtil.LbConfig
 
headersRead(Metadata) - Method in interface io.grpc.internal.ClientStreamListener
Called upon receiving all header information from the remote end-point.
Http2ClientStreamTransportState - Class in io.grpc.internal
Base implementation for client streams using HTTP2 as the transport.
Http2ClientStreamTransportState(int, StatsTraceContext, TransportTracer) - Constructor for class io.grpc.internal.Http2ClientStreamTransportState
 
Http2Ping - Class in io.grpc.internal
Represents an outstanding PING operation on an HTTP/2 channel.
Http2Ping(long, Stopwatch) - Constructor for class io.grpc.internal.Http2Ping
Creates a new ping operation.
http2ProcessingFailed(Status, boolean, Metadata) - Method in class io.grpc.internal.Http2ClientStreamTransportState
Called to process a failure in HTTP/2 processing.
HTTP_METHOD - Static variable in class io.grpc.internal.GrpcUtil
The HTTP method used for GRPC requests.
httpStatusToGrpcStatus(int) - Static method in class io.grpc.internal.GrpcUtil
Maps HTTP error response status codes to transport codes, as defined in http-grpc-status-mapping.md.

I

idleTimeout(long, TimeUnit) - Method in class io.grpc.internal.AbstractManagedChannelImplBuilder
 
ignoreClose(ReadableBuffer) - Static method in class io.grpc.internal.ReadableBuffers
Decorates the given ReadableBuffer to ignore calls to ReadableBuffer.close().
inboundDataReceived(ReadableBuffer) - Method in class io.grpc.internal.AbstractClientStream.TransportState
Processes the contents of a received data frame from the server.
inboundDataReceived(ReadableBuffer, boolean) - Method in class io.grpc.internal.AbstractServerStream.TransportState
Called in the transport thread to process the content of an inbound DATA frame from the client.
inboundHeaders() - Method in class io.grpc.util.ForwardingClientStreamTracer
 
inboundHeadersReceived(Metadata) - Method in class io.grpc.internal.AbstractClientStream.TransportState
Called by transport implementations when they receive headers.
inboundMessage(int) - Method in class io.grpc.internal.StatsTraceContext
inboundMessage(int) - Method in class io.grpc.util.ForwardingClientStreamTracer
 
inboundMessageRead(int, long, long) - Method in class io.grpc.internal.StatsTraceContext
inboundMessageRead(int, long, long) - Method in class io.grpc.util.ForwardingClientStreamTracer
 
inboundTrailers(Metadata) - Method in class io.grpc.util.ForwardingClientStreamTracer
 
inboundTrailersReceived(Metadata, Status) - Method in class io.grpc.internal.AbstractClientStream.TransportState
Processes the trailers and status from the server.
inboundUncompressedSize(long) - Method in class io.grpc.internal.StatsTraceContext
inboundUncompressedSize(long) - Method in class io.grpc.util.ForwardingClientStreamTracer
 
inboundWireSize(long) - Method in class io.grpc.internal.StatsTraceContext
inboundWireSize(long) - Method in class io.grpc.util.ForwardingClientStreamTracer
 
InProcessChannelBuilder - Class in io.grpc.inprocess
Builder for a channel that issues in-process requests.
InProcessServerBuilder - Class in io.grpc.inprocess
Builder for a server that services in-process requests.
InProcessSocketAddress - Class in io.grpc.inprocess
Custom SocketAddress class for InProcessTransport.
InProcessSocketAddress(String) - Constructor for class io.grpc.inprocess.InProcessSocketAddress
 
InsightBuilder - Class in io.grpc.internal
Builds a concise and readable string that gives insight of the concerned part of the system.
InsightBuilder() - Constructor for class io.grpc.internal.InsightBuilder
 
INSTANCE - Static variable in class io.grpc.internal.NoopClientStream
 
instance() - Static method in class io.grpc.util.TransmitStatusRuntimeExceptionInterceptor
 
intercept(List<ClientInterceptor>) - Method in class io.grpc.internal.AbstractManagedChannelImplBuilder
 
intercept(ClientInterceptor...) - Method in class io.grpc.internal.AbstractManagedChannelImplBuilder
 
intercept(ServerInterceptor) - Method in class io.grpc.internal.AbstractServerImplBuilder
 
interceptCall(ServerCall<ReqT, RespT>, Metadata, ServerCallHandler<ReqT, RespT>) - Method in class io.grpc.util.TransmitStatusRuntimeExceptionInterceptor
 
InternalServer - Interface in io.grpc.internal
An object that accepts new incoming connections.
InUseStateAggregator<T> - Class in io.grpc.internal
Aggregates the in-use state of a set of objects.
InUseStateAggregator() - Constructor for class io.grpc.internal.InUseStateAggregator
 
io.grpc.inprocess - package io.grpc.inprocess
The in-process transport which is for when a server is in the same process as the client.
io.grpc.internal - package io.grpc.internal
Interfaces and implementations that are internal to gRPC.
io.grpc.util - package io.grpc.util
Utilities with advanced features in the core layer that user can optionally use.
IS_RESTRICTED_APPENGINE - Static variable in class io.grpc.internal.GrpcUtil
 
isAvailable() - Method in class io.grpc.internal.DnsNameResolverProvider
 
isAvailable() - Method in class io.grpc.internal.PickFirstLoadBalancerProvider
 
isClosed() - Method in interface io.grpc.internal.Framer
Returns whether the framer is closed.
isClosed() - Method in class io.grpc.internal.MessageDeframer
Indicates whether or not this deframer has been closed.
isClosed() - Method in class io.grpc.internal.MessageFramer
Indicates whether or not this framer has been closed via a call to either MessageFramer.close() or MessageFramer.dispose().
isGrpcContentType(String) - Static method in class io.grpc.internal.GrpcUtil
Indicates whether or not the given value is a valid gRPC content-type.
isInUse() - Method in class io.grpc.internal.InUseStateAggregator
 
isOutboundClosed() - Method in class io.grpc.internal.AbstractClientStream.TransportState
 
isReady() - Method in class io.grpc.internal.AbstractClientStream
 
isReady() - Method in class io.grpc.internal.AbstractServerStream
 
isReady() - Method in class io.grpc.internal.AbstractStream
 
isReady() - Method in class io.grpc.internal.NoopClientStream
 
isReady() - Method in interface io.grpc.internal.Stream
If true, indicates that the transport is capable of sending additional messages without requiring excessive buffering internally.
isShutdown() - Method in class io.grpc.internal.ServerImpl
 
isTerminated() - Method in class io.grpc.internal.ServerImpl
 

J

JsonParser - Class in io.grpc.internal
Parses JSON with as few preconceived notions as possible.

K

KEEPALIVE_TIME_NANOS_DISABLED - Static variable in class io.grpc.internal.GrpcUtil
The magic keepalive time value that disables client keepalive.
KeepAliveManager - Class in io.grpc.internal
Manages keepalive pings.
KeepAliveManager(KeepAliveManager.KeepAlivePinger, ScheduledExecutorService, long, long, boolean) - Constructor for class io.grpc.internal.KeepAliveManager
Creates a KeepAliverManager.
KeepAliveManager.ClientKeepAlivePinger - Class in io.grpc.internal
KeepAliveManager.KeepAlivePinger - Interface in io.grpc.internal
 
keepAliveTime(long, TimeUnit) - Method in class io.grpc.inprocess.InProcessChannelBuilder
Does nothing.
keepAliveTimeout(long, TimeUnit) - Method in class io.grpc.inprocess.InProcessChannelBuilder
Does nothing.
keepAliveWithoutCalls(boolean) - Method in class io.grpc.inprocess.InProcessChannelBuilder
Does nothing.

L

LbConfig(String, Map<String, ?>) - Constructor for class io.grpc.internal.ServiceConfigUtil.LbConfig
 
listener() - Method in class io.grpc.internal.AbstractClientStream.TransportState
 
listener() - Method in class io.grpc.internal.AbstractServerStream.TransportState
 
listener() - Method in class io.grpc.internal.AbstractStream.TransportState
Override this method to provide a stream listener.
localBytes - Variable in class io.grpc.internal.TransportTracer.FlowControlWindows
 
LogExceptionRunnable - Class in io.grpc.internal
A simple wrapper for a Runnable that logs any exception thrown by it, before re-throwing it.
LogExceptionRunnable(Runnable) - Constructor for class io.grpc.internal.LogExceptionRunnable
 
LongCounter - Interface in io.grpc.internal
An interface for a long base counter.
lookupMethod(String, String) - Method in class io.grpc.util.MutableHandlerRegistry
Note: This does not actually honor the authority provided.

M

ManagedClientTransport - Interface in io.grpc.internal
A ClientTransport that has life-cycle management.
ManagedClientTransport.Listener - Interface in io.grpc.internal
Receives notifications for the transport life-cycle events.
maxHedgedAttempts(int) - Method in class io.grpc.internal.AbstractManagedChannelImplBuilder
 
maxInboundMessageSize(int) - Method in class io.grpc.inprocess.InProcessChannelBuilder
 
maxInboundMessageSize(int) - Method in class io.grpc.internal.AbstractManagedChannelImplBuilder
Sets the maximum message size allowed for a single gRPC frame.
maxInboundMessageSize() - Method in class io.grpc.internal.AbstractManagedChannelImplBuilder
 
maxInboundMetadataSize(int) - Method in class io.grpc.inprocess.InProcessChannelBuilder
Sets the maximum size of metadata allowed to be received.
maxInboundMetadataSize(int) - Method in class io.grpc.inprocess.InProcessServerBuilder
Sets the maximum size of metadata allowed to be received.
maxRetryAttempts(int) - Method in class io.grpc.internal.AbstractManagedChannelImplBuilder
 
maxTraceEvents(int) - Method in class io.grpc.internal.AbstractManagedChannelImplBuilder
 
MESSAGE_ACCEPT_ENCODING - Static variable in class io.grpc.internal.GrpcUtil
The accepted message encodings (i.e.
MESSAGE_ACCEPT_ENCODING_KEY - Static variable in class io.grpc.internal.GrpcUtil
Metadata.Key for the accepted message encodings header.
MESSAGE_ENCODING - Static variable in class io.grpc.internal.GrpcUtil
The message encoding (i.e.
MESSAGE_ENCODING_KEY - Static variable in class io.grpc.internal.GrpcUtil
Metadata.Key for the message encoding header.
MessageDeframer - Class in io.grpc.internal
Deframer for GRPC frames.
MessageDeframer(MessageDeframer.Listener, Decompressor, int, StatsTraceContext, TransportTracer) - Constructor for class io.grpc.internal.MessageDeframer
Create a deframer.
MessageDeframer.Listener - Interface in io.grpc.internal
A listener of deframing events.
MessageFramer - Class in io.grpc.internal
Encodes gRPC messages to be delivered via the transport layer which implements MessageFramer.Sink.
MessageFramer(MessageFramer.Sink, WritableBufferAllocator, StatsTraceContext) - Constructor for class io.grpc.internal.MessageFramer
Creates a MessageFramer.
MessageFramer.Sink - Interface in io.grpc.internal
Sink implemented by the transport layer to receive frames and forward them to their destination.
messagesAvailable(StreamListener.MessageProducer) - Method in class io.grpc.internal.AbstractStream.TransportState
 
messagesAvailable(StreamListener.MessageProducer) - Method in class io.grpc.internal.ApplicationThreadDeframer
 
messagesAvailable(StreamListener.MessageProducer) - Method in interface io.grpc.internal.MessageDeframer.Listener
Called to deliver the next complete message.
messagesAvailable(StreamListener.MessageProducer) - Method in interface io.grpc.internal.StreamListener
Called upon receiving a message from the remote end-point.
MutableHandlerRegistry - Class in io.grpc.util
Default implementation of MutableHandlerRegistry.
MutableHandlerRegistry() - Constructor for class io.grpc.util.MutableHandlerRegistry
 

N

NAME_RESOLVER_SERVICE_CONFIG - Static variable in class io.grpc.internal.GrpcAttributes
Attribute key for service config.
nameResolverFactory(NameResolver.Factory) - Method in class io.grpc.internal.AbstractManagedChannelImplBuilder
 
newClientContext(CallOptions, Attributes, Metadata) - Static method in class io.grpc.internal.StatsTraceContext
Factory method for the client-side.
newClientTransport(SocketAddress, ClientTransportFactory.ClientTransportOptions, ChannelLogger) - Method in interface io.grpc.internal.ClientTransportFactory
Creates an unstarted transport for exclusive use.
newLoadBalancer(LoadBalancer.Helper) - Method in class io.grpc.internal.AutoConfiguredLoadBalancerFactory
 
newLoadBalancer(LoadBalancer.Helper) - Method in class io.grpc.internal.PickFirstLoadBalancerProvider
 
newNameResolver(URI, NameResolver.Args) - Method in class io.grpc.internal.DnsNameResolverProvider
 
newServerContext(List<? extends ServerStreamTracer.Factory>, String, Metadata) - Static method in class io.grpc.internal.StatsTraceContext
Factory method for the server-side.
newStream(MethodDescriptor<?, ?>, Metadata, CallOptions) - Method in interface io.grpc.internal.ClientTransport
Creates a new stream for sending messages to a remote end-point.
next() - Method in interface io.grpc.internal.StreamListener.MessageProducer
Returns the next gRPC message, if the data has been received by the deframer and the application has requested another message.
nextBackoffNanos() - Method in interface io.grpc.internal.BackoffPolicy
 
nextBackoffNanos() - Method in class io.grpc.internal.ExponentialBackoffPolicy
 
NOOP - Static variable in class io.grpc.internal.StatsTraceContext
 
NOOP_PROXY_DETECTOR - Static variable in class io.grpc.internal.GrpcUtil
A proxy detector that always claims no proxy is needed.
NoopClientStream - Class in io.grpc.internal
An implementation of ClientStream that silently does nothing for the operations.
NoopClientStream() - Constructor for class io.grpc.internal.NoopClientStream
 
notifyFailed(ClientTransport.PingCallback, Executor, Throwable) - Static method in class io.grpc.internal.Http2Ping
Notifies the given callback that the ping operation failed.

O

ObjectPool<T> - Interface in io.grpc.internal
An object pool.
onDataReceived() - Method in class io.grpc.internal.KeepAliveManager
Transport has received some data so that we can delay sending keepalives.
onFailure(Throwable) - Method in interface io.grpc.internal.ClientTransport.PingCallback
Invoked when a ping fails.
onPingTimeout() - Method in class io.grpc.internal.KeepAliveManager.ClientKeepAlivePinger
 
onPingTimeout() - Method in interface io.grpc.internal.KeepAliveManager.KeepAlivePinger
Callback when Ping Ack was not received in KEEPALIVE_TIMEOUT.
onReady() - Method in interface io.grpc.internal.StreamListener
This indicates that the transport is now capable of sending additional messages without requiring excessive buffering internally.
onSendingBytes(int) - Method in class io.grpc.internal.AbstractStream
Event handler to be called by the subclass when a number of bytes are being queued for sending to the remote endpoint.
onSentBytes(int) - Method in class io.grpc.internal.AbstractStream.TransportState
Event handler to be called by the subclass when a number of bytes has been sent to the remote endpoint.
onStreamAllocated() - Method in class io.grpc.internal.AbstractServerStream.TransportState
 
onStreamAllocated() - Method in class io.grpc.internal.AbstractStream.TransportState
Event handler to be called by the subclass when the stream's headers have passed any connection flow control (i.e., MAX_CONCURRENT_STREAMS).
onStreamDeallocated() - Method in class io.grpc.internal.AbstractStream.TransportState
Notify that the stream does not exist in a usable state any longer.
onSuccess(long) - Method in interface io.grpc.internal.ClientTransport.PingCallback
Invoked when a ping is acknowledged.
onTransportActive() - Method in class io.grpc.internal.KeepAliveManager
Transport has active streams.
onTransportIdle() - Method in class io.grpc.internal.KeepAliveManager
Transport has finished all streams.
onTransportStarted() - Method in class io.grpc.internal.KeepAliveManager
Start keepalive monitoring.
onTransportTermination() - Method in class io.grpc.internal.KeepAliveManager
Transport is being terminated.
openStream(ReadableBuffer, boolean) - Static method in class io.grpc.internal.ReadableBuffers
Creates a new InputStream backed by the given buffer.
outboundHeaders() - Method in class io.grpc.util.ForwardingClientStreamTracer
 
outboundMessage(int) - Method in class io.grpc.internal.StatsTraceContext
outboundMessage(int) - Method in class io.grpc.util.ForwardingClientStreamTracer
 
outboundMessageSent(int, long, long) - Method in class io.grpc.internal.StatsTraceContext
outboundMessageSent(int, long, long) - Method in class io.grpc.util.ForwardingClientStreamTracer
 
outboundUncompressedSize(long) - Method in class io.grpc.internal.StatsTraceContext
outboundUncompressedSize(long) - Method in class io.grpc.util.ForwardingClientStreamTracer
 
outboundWireSize(long) - Method in class io.grpc.internal.StatsTraceContext
outboundWireSize(long) - Method in class io.grpc.util.ForwardingClientStreamTracer
 
overrideAuthority(String) - Method in class io.grpc.internal.AbstractManagedChannelImplBuilder
 
overrideCensusStatsModule(CensusStatsModule) - Method in class io.grpc.internal.AbstractManagedChannelImplBuilder
Override the default stats implementation.
overrideCensusStatsModule(CensusStatsModule) - Method in class io.grpc.internal.AbstractServerImplBuilder
Override the default stats implementation.

P

parse(String) - Static method in class io.grpc.internal.JsonParser
Parses a json string, returning either a Map<String, ?>, List<?>, String, Double, Boolean, or null.
parseLoadBalancingPolicyConfig(Map<String, ?>) - Method in class io.grpc.internal.PickFirstLoadBalancerProvider
 
payload() - Method in class io.grpc.internal.Http2Ping
Returns the expected ping payload for this outstanding operation.
perRpcBufferLimit(long) - Method in class io.grpc.internal.AbstractManagedChannelImplBuilder
 
PickFirstLoadBalancerProvider - Class in io.grpc.internal
Provider for the "pick_first" balancing policy.
PickFirstLoadBalancerProvider() - Constructor for class io.grpc.internal.PickFirstLoadBalancerProvider
 
ping(ClientTransport.PingCallback, Executor) - Method in interface io.grpc.internal.ClientTransport
Pings a remote endpoint.
ping() - Method in class io.grpc.internal.KeepAliveManager.ClientKeepAlivePinger
 
ping() - Method in interface io.grpc.internal.KeepAliveManager.KeepAlivePinger
Sends out a keep-alive ping.
priority() - Method in class io.grpc.internal.DnsNameResolverProvider
 
Provider() - Constructor for class io.grpc.internal.ExponentialBackoffPolicy.Provider
 
proxyDetector(ProxyDetector) - Method in class io.grpc.internal.AbstractManagedChannelImplBuilder
 

R

read() - Method in interface io.grpc.internal.TransportTracer.FlowControlReader
 
ReadableBuffer - Interface in io.grpc.internal
Interface for an abstract byte buffer.
ReadableBuffers - Class in io.grpc.internal
Utility methods for creating ReadableBuffer instances.
readableBytes() - Method in class io.grpc.internal.CompositeReadableBuffer
 
readableBytes() - Method in class io.grpc.internal.ForwardingReadableBuffer
 
readableBytes() - Method in interface io.grpc.internal.ReadableBuffer
Gets the current number of readable bytes remaining in this buffer.
readableBytes() - Method in interface io.grpc.internal.WritableBuffer
Returns the number of bytes one can read from the buffer.
readArray(ReadableBuffer) - Static method in class io.grpc.internal.ReadableBuffers
Reads an entire ReadableBuffer to a new array.
readAsString(ReadableBuffer, Charset) - Static method in class io.grpc.internal.ReadableBuffers
Reads the entire ReadableBuffer to a new String with the given charset.
readAsStringUtf8(ReadableBuffer) - Static method in class io.grpc.internal.ReadableBuffers
Reads the entire ReadableBuffer to a new String using UTF-8 decoding.
readBytes(byte[], int, int) - Method in class io.grpc.internal.CompositeReadableBuffer
 
readBytes(ByteBuffer) - Method in class io.grpc.internal.CompositeReadableBuffer
 
readBytes(OutputStream, int) - Method in class io.grpc.internal.CompositeReadableBuffer
 
readBytes(int) - Method in class io.grpc.internal.CompositeReadableBuffer
 
readBytes(byte[], int, int) - Method in class io.grpc.internal.ForwardingReadableBuffer
 
readBytes(ByteBuffer) - Method in class io.grpc.internal.ForwardingReadableBuffer
 
readBytes(OutputStream, int) - Method in class io.grpc.internal.ForwardingReadableBuffer
 
readBytes(int) - Method in class io.grpc.internal.ForwardingReadableBuffer
 
readBytes(byte[], int, int) - Method in interface io.grpc.internal.ReadableBuffer
Reads length bytes from this buffer and writes them to the destination array.
readBytes(ByteBuffer) - Method in interface io.grpc.internal.ReadableBuffer
Reads from this buffer until the destination's position reaches its limit, and increases the read position by the number of the transferred bytes.
readBytes(OutputStream, int) - Method in interface io.grpc.internal.ReadableBuffer
Reads length bytes from this buffer and writes them to the destination stream.
readBytes(int) - Method in interface io.grpc.internal.ReadableBuffer
Reads length bytes from this buffer and returns a new Buffer containing them.
readInt() - Method in class io.grpc.internal.AbstractReadableBuffer
 
readInt() - Method in class io.grpc.internal.ForwardingReadableBuffer
 
readInt() - Method in interface io.grpc.internal.ReadableBuffer
Reads a 4-byte signed integer from this buffer using big-endian byte ordering.
readUnsignedByte() - Method in class io.grpc.internal.CompositeReadableBuffer
 
readUnsignedByte() - Method in class io.grpc.internal.ForwardingReadableBuffer
 
readUnsignedByte() - Method in interface io.grpc.internal.ReadableBuffer
Reads the next unsigned byte from this buffer and increments the read position by 1.
ReflectionLongAdderCounter - Class in io.grpc.internal
A LongCounter that is implemented with a JDK8 LongAdder.
refreshNameResolution() - Method in class io.grpc.util.ForwardingLoadBalancerHelper
 
release(SharedResourceHolder.Resource<T>, T) - Static method in class io.grpc.internal.SharedResourceHolder
Releases an instance of the given resource.
release() - Method in interface io.grpc.internal.WritableBuffer
Releases the buffer, indicating to the WritableBufferAllocator that this buffer is no longer used and its resources can be reused.
remoteBytes - Variable in class io.grpc.internal.TransportTracer.FlowControlWindows
 
removeService(ServerServiceDefinition) - Method in class io.grpc.util.MutableHandlerRegistry
Removes a registered service
reportKeepAliveSent() - Method in class io.grpc.internal.TransportTracer
Reports that a keep alive message was sent.
reportLocalStreamStarted() - Method in class io.grpc.internal.TransportTracer
Called by the client to report a stream has started.
reportMessageReceived() - Method in class io.grpc.internal.TransportTracer
Reports that a message was successfully received.
reportMessageSent(int) - Method in class io.grpc.internal.TransportTracer
Reports that some messages were successfully sent.
reportRemoteStreamStarted() - Method in class io.grpc.internal.TransportTracer
Called by the server to report a stream has started.
reportStreamClosed(boolean) - Method in class io.grpc.internal.TransportTracer
Reports that a stream closed with the specified Status.
request(int) - Method in class io.grpc.internal.AbstractClientStream
 
request(int) - Method in interface io.grpc.internal.AbstractClientStream.Sink
Requests up to the given number of messages from the call to be delivered to the client.
request(int) - Method in class io.grpc.internal.AbstractServerStream
 
request(int) - Method in interface io.grpc.internal.AbstractServerStream.Sink
Requests up to the given number of messages from the call to be delivered.
request(int) - Method in class io.grpc.internal.ApplicationThreadDeframer
 
request(int) - Method in interface io.grpc.internal.Deframer
Requests up to the given number of messages from the call.
request(int) - Method in class io.grpc.internal.MessageDeframer
 
request(int) - Method in class io.grpc.internal.NoopClientStream
 
request(int) - Method in interface io.grpc.internal.Stream
Requests up to the given number of messages from the call to be delivered via StreamListener.messagesAvailable(StreamListener.MessageProducer).
requestConnection() - Method in class io.grpc.util.ForwardingLoadBalancer
 
requestConnection() - Method in class io.grpc.util.ForwardingSubchannel
 
requestMessagesFromDeframer(int) - Method in class io.grpc.internal.AbstractStream.TransportState
Called to request the given number of messages from the deframer.
retryBufferSize(long) - Method in class io.grpc.internal.AbstractManagedChannelImplBuilder
 
returnObject(Object) - Method in class io.grpc.internal.FixedObjectPool
 
returnObject(Object) - Method in interface io.grpc.internal.ObjectPool
Return the object to the pool.
returnObject(Object) - Method in class io.grpc.internal.SharedResourcePool
 
RPC_CLIENT_ERROR_COUNT - Static variable in class io.grpc.internal.DeprecatedCensusConstants
 
RPC_CLIENT_FINISHED_COUNT - Static variable in class io.grpc.internal.DeprecatedCensusConstants
 
RPC_CLIENT_REQUEST_BYTES - Static variable in class io.grpc.internal.DeprecatedCensusConstants
 
RPC_CLIENT_REQUEST_COUNT - Static variable in class io.grpc.internal.DeprecatedCensusConstants
 
RPC_CLIENT_RESPONSE_BYTES - Static variable in class io.grpc.internal.DeprecatedCensusConstants
 
RPC_CLIENT_RESPONSE_COUNT - Static variable in class io.grpc.internal.DeprecatedCensusConstants
 
RPC_CLIENT_ROUNDTRIP_LATENCY - Static variable in class io.grpc.internal.DeprecatedCensusConstants
 
RPC_CLIENT_SERVER_ELAPSED_TIME - Static variable in class io.grpc.internal.DeprecatedCensusConstants
 
RPC_CLIENT_STARTED_COUNT - Static variable in class io.grpc.internal.DeprecatedCensusConstants
 
RPC_CLIENT_UNCOMPRESSED_REQUEST_BYTES - Static variable in class io.grpc.internal.DeprecatedCensusConstants
 
RPC_CLIENT_UNCOMPRESSED_RESPONSE_BYTES - Static variable in class io.grpc.internal.DeprecatedCensusConstants
 
RPC_METHOD - Static variable in class io.grpc.internal.DeprecatedCensusConstants
 
RPC_SERVER_ERROR_COUNT - Static variable in class io.grpc.internal.DeprecatedCensusConstants
 
RPC_SERVER_FINISHED_COUNT - Static variable in class io.grpc.internal.DeprecatedCensusConstants
 
RPC_SERVER_REQUEST_BYTES - Static variable in class io.grpc.internal.DeprecatedCensusConstants
 
RPC_SERVER_REQUEST_COUNT - Static variable in class io.grpc.internal.DeprecatedCensusConstants
 
RPC_SERVER_RESPONSE_BYTES - Static variable in class io.grpc.internal.DeprecatedCensusConstants
 
RPC_SERVER_RESPONSE_COUNT - Static variable in class io.grpc.internal.DeprecatedCensusConstants
 
RPC_SERVER_SERVER_ELAPSED_TIME - Static variable in class io.grpc.internal.DeprecatedCensusConstants
 
RPC_SERVER_SERVER_LATENCY - Static variable in class io.grpc.internal.DeprecatedCensusConstants
 
RPC_SERVER_STARTED_COUNT - Static variable in class io.grpc.internal.DeprecatedCensusConstants
 
RPC_SERVER_UNCOMPRESSED_REQUEST_BYTES - Static variable in class io.grpc.internal.DeprecatedCensusConstants
 
RPC_SERVER_UNCOMPRESSED_RESPONSE_BYTES - Static variable in class io.grpc.internal.DeprecatedCensusConstants
 
RPC_STATUS - Static variable in class io.grpc.internal.DeprecatedCensusConstants
 
run() - Method in class io.grpc.internal.LogExceptionRunnable
 
run() - Method in class io.grpc.internal.SerializingExecutor
 
runSerialized(Runnable) - Method in class io.grpc.util.ForwardingLoadBalancerHelper
Deprecated.

S

scheduledExecutorService(ScheduledExecutorService) - Method in class io.grpc.inprocess.InProcessChannelBuilder
Provides a custom scheduled executor service.
scheduledExecutorService(ScheduledExecutorService) - Method in class io.grpc.inprocess.InProcessServerBuilder
Provides a custom scheduled executor service.
SerializingExecutor - Class in io.grpc.internal
Executor ensuring that all Runnable tasks submitted are executed in order using the provided Executor, and serially such that no two will ever be running at the same time.
SerializingExecutor(Executor) - Constructor for class io.grpc.internal.SerializingExecutor
Creates a SerializingExecutor, running tasks using executor.
SERVER_KEEPALIVE_TIME_NANOS_DISABLED - Static variable in class io.grpc.internal.GrpcUtil
The magic keepalive time value that disables keepalive.
serverCallStarted(ServerStreamTracer.ServerCallInfo<?, ?>) - Method in class io.grpc.internal.StatsTraceContext
serverFilterContext(Context) - Method in class io.grpc.internal.StatsTraceContext
ServerImpl - Class in io.grpc.internal
Default implementation of Server, for creation by transports.
ServerListener - Interface in io.grpc.internal
A listener to a server for transport creation events.
serverShutdown() - Method in interface io.grpc.internal.ServerListener
The server is shutting down.
ServerStream - Interface in io.grpc.internal
Extension of Stream to support server-side termination semantics.
ServerStreamListener - Interface in io.grpc.internal
An observer of server-side stream events.
ServerTransport - Interface in io.grpc.internal
An inbound connection.
ServerTransportListener - Interface in io.grpc.internal
A observer of a server-side transport for stream creation events.
ServiceConfigUtil - Class in io.grpc.internal
Helper utility to work with service configs.
ServiceConfigUtil.LbConfig - Class in io.grpc.internal
A LoadBalancingConfig that includes the policy name (the key) and its raw config value (parsed JSON).
setAuthority(String) - Method in interface io.grpc.internal.ClientStream
Override the default authority with authority.
setAuthority(String) - Method in class io.grpc.internal.ClientTransportFactory.ClientTransportOptions
Sets the non-null authority.
setAuthority(String) - Method in class io.grpc.internal.NoopClientStream
 
setBinaryLog(BinaryLog) - Method in class io.grpc.internal.AbstractManagedChannelImplBuilder
 
setBinaryLog(BinaryLog) - Method in class io.grpc.internal.AbstractServerImplBuilder
 
setChannelLogger(ChannelLogger) - Method in class io.grpc.internal.ClientTransportFactory.ClientTransportOptions
 
setCompressor(Compressor) - Method in class io.grpc.internal.AbstractStream
 
setCompressor(Compressor) - Method in interface io.grpc.internal.Framer
Set the compressor used for compression.
setCompressor(Compressor) - Method in class io.grpc.internal.MessageFramer
 
setCompressor(Compressor) - Method in class io.grpc.internal.NoopClientStream
 
setCompressor(Compressor) - Method in interface io.grpc.internal.Stream
Sets the compressor on the framer.
setDeadline(Deadline) - Method in class io.grpc.internal.AbstractClientStream
 
setDeadline(Deadline) - Method in interface io.grpc.internal.ClientStream
Sets the effective deadline of the RPC.
setDeadline(Deadline) - Method in class io.grpc.internal.NoopClientStream
 
setDecompressor(Decompressor) - Method in class io.grpc.internal.AbstractServerStream
 
setDecompressor(Decompressor) - Method in class io.grpc.internal.AbstractStream.TransportState
 
setDecompressor(Decompressor) - Method in class io.grpc.internal.ApplicationThreadDeframer
 
setDecompressor(Decompressor) - Method in interface io.grpc.internal.Deframer
Sets the decompressor available to use.
setDecompressor(Decompressor) - Method in class io.grpc.internal.MessageDeframer
 
setDecompressor(Decompressor) - Method in interface io.grpc.internal.ServerStream
Sets the decompressor on the deframer.
setDecompressorRegistry(DecompressorRegistry) - Method in class io.grpc.internal.AbstractClientStream
 
setDecompressorRegistry(DecompressorRegistry) - Method in interface io.grpc.internal.ClientStream
Sets the registry to find a decompressor for the framer.
setDecompressorRegistry(DecompressorRegistry) - Method in class io.grpc.internal.NoopClientStream
 
setEagAttributes(Attributes) - Method in class io.grpc.internal.ClientTransportFactory.ClientTransportOptions
Sets the non-null EquivalentAddressGroup's attributes.
setFlowControlWindowReader(TransportTracer.FlowControlReader) - Method in class io.grpc.internal.TransportTracer
Registers a TransportTracer.FlowControlReader that can be used to read the local and remote flow control window sizes.
setFullStreamDecompression(boolean) - Method in class io.grpc.internal.AbstractClientStream
 
setFullStreamDecompression(boolean) - Method in interface io.grpc.internal.ClientStream
Enables full-stream decompression, allowing the client stream to use GzipInflatingBuffer to decode inbound GZIP compressed streams.
setFullStreamDecompression(boolean) - Method in class io.grpc.internal.NoopClientStream
 
setFullStreamDecompressor(GzipInflatingBuffer) - Method in class io.grpc.internal.AbstractStream.TransportState
 
setFullStreamDecompressor(GzipInflatingBuffer) - Method in class io.grpc.internal.ApplicationThreadDeframer
 
setFullStreamDecompressor(GzipInflatingBuffer) - Method in interface io.grpc.internal.Deframer
Sets the decompressor used for full-stream decompression.
setFullStreamDecompressor(GzipInflatingBuffer) - Method in class io.grpc.internal.MessageDeframer
 
setHttpConnectProxiedSocketAddress(HttpConnectProxiedSocketAddress) - Method in class io.grpc.internal.ClientTransportFactory.ClientTransportOptions
 
setListener(ClientStreamListener) - Method in class io.grpc.internal.AbstractClientStream.TransportState
 
setListener(ServerStreamListener) - Method in class io.grpc.internal.AbstractServerStream
 
setListener(ServerStreamListener) - Method in class io.grpc.internal.AbstractServerStream.TransportState
Sets the listener to receive notifications.
setListener(ServerStreamListener) - Method in interface io.grpc.internal.ServerStream
Sets the server stream listener.
setMaxInboundMessageSize(int) - Method in class io.grpc.internal.AbstractClientStream
 
setMaxInboundMessageSize(int) - Method in class io.grpc.internal.ApplicationThreadDeframer
 
setMaxInboundMessageSize(int) - Method in interface io.grpc.internal.ClientStream
Sets the max size accepted from the remote endpoint.
setMaxInboundMessageSize(int) - Method in interface io.grpc.internal.Deframer
 
setMaxInboundMessageSize(int) - Method in class io.grpc.internal.MessageDeframer
 
setMaxInboundMessageSize(int) - Method in class io.grpc.internal.NoopClientStream
 
setMaxOutboundMessageSize(int) - Method in class io.grpc.internal.AbstractClientStream
 
setMaxOutboundMessageSize(int) - Method in interface io.grpc.internal.ClientStream
Sets the max size sent to the remote endpoint.
setMaxOutboundMessageSize(int) - Method in interface io.grpc.internal.Framer
Set a size limit for each outbound message.
setMaxOutboundMessageSize(int) - Method in class io.grpc.internal.MessageFramer
 
setMaxOutboundMessageSize(int) - Method in class io.grpc.internal.NoopClientStream
 
setMessageCompression(boolean) - Method in class io.grpc.internal.AbstractStream
 
setMessageCompression(boolean) - Method in interface io.grpc.internal.Framer
Enable or disable compression.
setMessageCompression(boolean) - Method in class io.grpc.internal.MessageFramer
 
setMessageCompression(boolean) - Method in class io.grpc.internal.NoopClientStream
 
setMessageCompression(boolean) - Method in interface io.grpc.internal.Stream
Enables per-message compression, if an encoding type has been negotiated.
setStatsEnabled(boolean) - Method in class io.grpc.internal.AbstractManagedChannelImplBuilder
Disable or enable stats features.
setStatsEnabled(boolean) - Method in class io.grpc.internal.AbstractServerImplBuilder
Disable or enable stats features.
setStatsRecordFinishedRpcs(boolean) - Method in class io.grpc.internal.AbstractManagedChannelImplBuilder
Disable or enable stats recording for RPC completions.
setStatsRecordFinishedRpcs(boolean) - Method in class io.grpc.internal.AbstractServerImplBuilder
Disable or enable stats recording for RPC completions.
setStatsRecordRealTimeMetrics(boolean) - Method in class io.grpc.internal.AbstractManagedChannelImplBuilder
Disable or enable real-time metrics recording.
setStatsRecordRealTimeMetrics(boolean) - Method in class io.grpc.internal.AbstractServerImplBuilder
Disable or enable real-time metrics recording.
setStatsRecordStartedRpcs(boolean) - Method in class io.grpc.internal.AbstractManagedChannelImplBuilder
Disable or enable stats recording for RPC upstarts.
setStatsRecordStartedRpcs(boolean) - Method in class io.grpc.internal.AbstractServerImplBuilder
Disable or enable stats recording for RPC upstarts.
setTracingEnabled(boolean) - Method in class io.grpc.internal.AbstractManagedChannelImplBuilder
Disable or enable tracing features.
setTracingEnabled(boolean) - Method in class io.grpc.internal.AbstractServerImplBuilder
Disable or enable tracing features.
setTransportTracerFactory(TransportTracer.Factory) - Method in class io.grpc.internal.AbstractServerImplBuilder
 
setUserAgent(String) - Method in class io.grpc.internal.ClientTransportFactory.ClientTransportOptions
 
SHARED_CHANNEL_EXECUTOR - Static variable in class io.grpc.internal.GrpcUtil
Shared executor for channels.
SharedResourceHolder - Class in io.grpc.internal
A holder for shared resource singletons.
SharedResourceHolder.Resource<T> - Interface in io.grpc.internal
Defines a resource, and the way to create and destroy instances of it.
SharedResourcePool<T> - Class in io.grpc.internal
An ObjectPool backed by a SharedResourceHolder.Resource.
shouldBeCountedForInUse() - Method in class io.grpc.internal.AbstractClientStream
Returns true if this stream should be counted when determining the in-use state of the transport.
shouldBeCountedForInUse(CallOptions) - Static method in class io.grpc.internal.GrpcUtil
Returns true if an RPC with the given properties should be counted when calculating the in-use state of a transport.
shutdown() - Method in interface io.grpc.internal.InternalServer
Initiates an orderly shutdown of the server.
shutdown(Status) - Method in interface io.grpc.internal.ManagedClientTransport
Initiates an orderly shutdown of the transport.
shutdown() - Method in class io.grpc.internal.ServerImpl
Initiates an orderly shutdown in which preexisting calls continue but new calls are rejected.
shutdown() - Method in interface io.grpc.internal.ServerTransport
Initiates an orderly shutdown of the transport.
shutdown() - Method in class io.grpc.util.ForwardingLoadBalancer
 
shutdown() - Method in class io.grpc.util.ForwardingSubchannel
 
shutdown() - Method in class io.grpc.util.GracefulSwitchLoadBalancer
 
shutdownNow(Status) - Method in interface io.grpc.internal.ManagedClientTransport
Initiates a forceful shutdown in which preexisting and new calls are closed.
shutdownNow() - Method in class io.grpc.internal.ServerImpl
 
shutdownNow(Status) - Method in interface io.grpc.internal.ServerTransport
Initiates a forceful shutdown in which preexisting and new calls are closed.
skipBytes(int) - Method in class io.grpc.internal.CompositeReadableBuffer
 
skipBytes(int) - Method in class io.grpc.internal.ForwardingReadableBuffer
 
skipBytes(int) - Method in interface io.grpc.internal.ReadableBuffer
Increments the read position by the given length.
start(ClientStreamListener) - Method in class io.grpc.internal.AbstractClientStream
 
start(ClientStreamListener) - Method in interface io.grpc.internal.ClientStream
Starts stream.
start(ClientStreamListener) - Method in class io.grpc.internal.FailingClientStream
 
start(ServerListener) - Method in interface io.grpc.internal.InternalServer
Starts transport.
start(ManagedClientTransport.Listener) - Method in interface io.grpc.internal.ManagedClientTransport
Starts transport.
start(ClientStreamListener) - Method in class io.grpc.internal.NoopClientStream
 
start() - Method in class io.grpc.internal.ServerImpl
Bind and start the server.
start(LoadBalancer.SubchannelStateListener) - Method in class io.grpc.util.ForwardingSubchannel
 
statsTraceContext() - Method in class io.grpc.internal.AbstractServerStream
 
statsTraceContext() - Method in interface io.grpc.internal.ServerStream
The context for recording stats and traces for this stream.
StatsTraceContext - Class in io.grpc.internal
The stats and tracing information for a stream.
status() - Method in enum io.grpc.internal.GrpcUtil.Http2Error
Gets the Status associated with this HTTP/2 code.
statusForCode(long) - Static method in enum io.grpc.internal.GrpcUtil.Http2Error
Looks up the Status from the given HTTP/2 error code.
STOPWATCH_SUPPLIER - Static variable in class io.grpc.internal.GrpcUtil
The factory of default Stopwatches.
Stream - Interface in io.grpc.internal
A single stream of communication between two end-points within a transport.
streamClosed(Status) - Method in class io.grpc.internal.StatsTraceContext
streamClosed(Status) - Method in class io.grpc.util.ForwardingClientStreamTracer
 
streamCreated(ServerStream, String, Metadata) - Method in interface io.grpc.internal.ServerTransportListener
Called when a new stream was created by the remote client.
streamId() - Method in interface io.grpc.internal.ServerStream
The HTTP/2 stream id, or -1 if not supported.
StreamListener - Interface in io.grpc.internal
An observer of Stream events.
StreamListener.MessageProducer - Interface in io.grpc.internal
A producer for deframed gRPC messages.
switchTo(LoadBalancerProvider) - Method in class io.grpc.util.GracefulSwitchLoadBalancer
Gracefully switch to a new load balancing policy.
SYSTEM_TIME_PROVIDER - Static variable in interface io.grpc.internal.TimeProvider
 

T

TE_HEADER - Static variable in class io.grpc.internal.GrpcUtil
Metadata.Key for the Transfer encoding.
TE_TRAILERS - Static variable in class io.grpc.internal.GrpcUtil
The TE (transport encoding) header for requests over HTTP/2.
TIMEOUT - Static variable in class io.grpc.internal.GrpcUtil
The Timeout header name.
TIMEOUT_KEY - Static variable in class io.grpc.internal.GrpcUtil
Metadata.Key for the timeout header.
TimeProvider - Interface in io.grpc.internal
Time source representing the current system time in nanos.
TIMER_SERVICE - Static variable in class io.grpc.internal.GrpcUtil
Shared single-threaded executor for managing channel timers.
toHttp2Headers(Metadata) - Static method in class io.grpc.internal.TransportFrameUtil
Transform the given headers to a format where only spec-compliant ASCII characters are allowed.
toRawSerializedHeaders(byte[][]) - Static method in class io.grpc.internal.TransportFrameUtil
Transform HTTP/2-compliant headers to the raw serialized format which can be deserialized by metadata marshallers.
toString() - Method in class io.grpc.inprocess.InProcessSocketAddress
 
toString() - Method in class io.grpc.internal.ForwardingReadableBuffer
 
toString() - Method in class io.grpc.internal.InsightBuilder
Get the resulting string.
toString() - Method in class io.grpc.internal.LogExceptionRunnable
 
toString() - Method in class io.grpc.internal.ServerImpl
 
toString() - Method in class io.grpc.internal.ServiceConfigUtil.LbConfig
 
toString() - Method in class io.grpc.util.ForwardingClientStreamTracer
 
toString() - Method in class io.grpc.util.ForwardingLoadBalancer
 
toString() - Method in class io.grpc.util.ForwardingLoadBalancerHelper
 
toString() - Method in class io.grpc.util.ForwardingSubchannel
 
TransmitStatusRuntimeExceptionInterceptor - Class in io.grpc.util
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.
transportCreated(ServerTransport) - Method in interface io.grpc.internal.ServerListener
Called upon the establishment of a new client connection.
transportDataReceived(ReadableBuffer, boolean) - Method in class io.grpc.internal.Http2ClientStreamTransportState
Called by subclasses whenever a data frame is received from the transport.
TransportFrameUtil - Class in io.grpc.internal
Utility functions for transport layer framing.
transportHeadersReceived(Metadata) - Method in class io.grpc.internal.Http2ClientStreamTransportState
Called by subclasses whenever Headers are received from the transport.
transportInUse(boolean) - Method in interface io.grpc.internal.ManagedClientTransport.Listener
Called whenever the transport's in-use state has changed.
transportReady() - Method in interface io.grpc.internal.ManagedClientTransport.Listener
The transport is ready to accept traffic, because the connection is established.
transportReady(Attributes) - Method in interface io.grpc.internal.ServerTransportListener
The transport has finished all handshakes and is ready to process streams.
transportReportStatus(Status, boolean, Metadata) - Method in class io.grpc.internal.AbstractClientStream.TransportState
Report stream closure with status to the application layer if not already reported.
transportReportStatus(Status, ClientStreamListener.RpcProgress, boolean, Metadata) - Method in class io.grpc.internal.AbstractClientStream.TransportState
Report stream closure with status to the application layer if not already reported.
transportReportStatus(Status) - Method in class io.grpc.internal.AbstractServerStream.TransportState
Notifies failure to the listener of the stream.
transportShutdown(Status) - Method in interface io.grpc.internal.ManagedClientTransport.Listener
The transport is shutting down.
transportState() - Method in class io.grpc.internal.AbstractClientStream
Obtain the transport state corresponding to this stream.
TransportState(int, StatsTraceContext, TransportTracer) - Constructor for class io.grpc.internal.AbstractClientStream.TransportState
 
transportState() - Method in class io.grpc.internal.AbstractServerStream
 
TransportState(int, StatsTraceContext, TransportTracer) - Constructor for class io.grpc.internal.AbstractServerStream.TransportState
 
transportState() - Method in class io.grpc.internal.AbstractStream
Obtain the transport state corresponding to this stream.
TransportState(int, StatsTraceContext, TransportTracer) - Constructor for class io.grpc.internal.AbstractStream.TransportState
 
transportTerminated() - Method in interface io.grpc.internal.ManagedClientTransport.Listener
The transport completed shutting down.
transportTerminated() - Method in interface io.grpc.internal.ServerTransportListener
The transport completed shutting down.
TransportTracer - Class in io.grpc.internal
A class for gathering statistics about a transport.
TransportTracer() - Constructor for class io.grpc.internal.TransportTracer
 
TransportTracer.Factory - Class in io.grpc.internal
 
TransportTracer.FlowControlReader - Interface in io.grpc.internal
An interface for reading the local and remote flow control windows of the transport.
TransportTracer.FlowControlWindows - Class in io.grpc.internal
A container that holds the local and remote flow control window sizes.
transportTracerFactory - Variable in class io.grpc.internal.AbstractManagedChannelImplBuilder
 
transportTrailersReceived(Metadata) - Method in class io.grpc.internal.Http2ClientStreamTransportState
Called by subclasses for the terminal trailer metadata on a stream.

U

unwrapLoadBalancingConfig(Map<String, ?>) - Static method in class io.grpc.internal.ServiceConfigUtil
Unwrap a LoadBalancingConfig JSON object into a ServiceConfigUtil.LbConfig.
unwrapLoadBalancingConfigList(List<Map<String, ?>>) - Static method in class io.grpc.internal.ServiceConfigUtil
Given a JSON list of LoadBalancingConfigs, and convert it into a list of LbConfig.
updateAddresses(List<EquivalentAddressGroup>) - Method in class io.grpc.util.ForwardingSubchannel
 
updateBalancingState(ConnectivityState, LoadBalancer.SubchannelPicker) - Method in class io.grpc.util.ForwardingLoadBalancerHelper
 
updateObjectInUse(T, boolean) - Method in class io.grpc.internal.InUseStateAggregator
Update the in-use state of an object.
updateOobChannelAddresses(ManagedChannel, EquivalentAddressGroup) - Method in class io.grpc.util.ForwardingLoadBalancerHelper
 
updateSubchannelAddresses(LoadBalancer.Subchannel, List<EquivalentAddressGroup>) - Method in class io.grpc.util.ForwardingLoadBalancerHelper
Deprecated.
US_ASCII - Static variable in class io.grpc.internal.GrpcUtil
 
usePlaintext(boolean) - Method in class io.grpc.inprocess.InProcessChannelBuilder
Deprecated.
usePlaintext() - Method in class io.grpc.inprocess.InProcessChannelBuilder
Does nothing.
USER_AGENT_KEY - Static variable in class io.grpc.internal.GrpcUtil
Metadata.Key for the Content-Type request/response header.
userAgent(String) - Method in class io.grpc.internal.AbstractManagedChannelImplBuilder
 
useTransportSecurity() - Method in class io.grpc.inprocess.InProcessChannelBuilder
Does nothing.
useTransportSecurity(File, File) - Method in class io.grpc.inprocess.InProcessServerBuilder
 

V

value() - Method in interface io.grpc.internal.LongCounter
Returns the value of this counter.
value() - Method in class io.grpc.internal.ReflectionLongAdderCounter
 
valueOf(String) - Static method in enum io.grpc.internal.ClientStreamListener.RpcProgress
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.grpc.internal.GrpcUtil.Http2Error
Returns the enum constant of this type with the specified name.
values() - Static method in enum io.grpc.internal.ClientStreamListener.RpcProgress
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.grpc.internal.GrpcUtil.Http2Error
Returns an array containing the constants of this enum type, in the order they are declared.

W

wrap(byte[]) - Static method in class io.grpc.internal.ReadableBuffers
Shortcut for wrap(bytes, 0, bytes.length.
wrap(byte[], int, int) - Static method in class io.grpc.internal.ReadableBuffers
Creates a new ReadableBuffer that is backed by the given byte array.
wrap(ByteBuffer) - Static method in class io.grpc.internal.ReadableBuffers
Creates a new ReadableBuffer that is backed by the given ByteBuffer.
WritableBuffer - Interface in io.grpc.internal
An interface for a byte buffer that can only be written to.
WritableBufferAllocator - Interface in io.grpc.internal
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.
writableBytes() - Method in interface io.grpc.internal.WritableBuffer
Returns the number of bytes one can write to the buffer.
write(byte[], int, int) - Method in interface io.grpc.internal.WritableBuffer
Appends length bytes to the buffer from the source array starting at srcIndex.
write(byte) - Method in interface io.grpc.internal.WritableBuffer
Appends a single byte to the buffer.
writeFrame(WritableBuffer, boolean, boolean, int) - Method in interface io.grpc.internal.AbstractClientStream.Sink
Sends an outbound frame to the remote end point.
writeFrame(WritableBuffer, boolean, int) - Method in interface io.grpc.internal.AbstractServerStream.Sink
Sends an outbound frame to the remote end point.
writeHeaders(Metadata, byte[]) - Method in interface io.grpc.internal.AbstractClientStream.Sink
Sends the request headers to the remote end point.
writeHeaders(Metadata) - Method in interface io.grpc.internal.AbstractServerStream.Sink
Sends response headers to the remote end point.
writeHeaders(Metadata) - Method in class io.grpc.internal.AbstractServerStream
 
writeHeaders(Metadata) - Method in interface io.grpc.internal.ServerStream
Writes custom metadata as headers on the response stream sent to the client.
writeMessage(InputStream) - Method in class io.grpc.internal.AbstractStream
 
writeMessage(InputStream) - Method in class io.grpc.internal.NoopClientStream
 
writeMessage(InputStream) - Method in interface io.grpc.internal.Stream
Writes a message payload to the remote end-point.
writePayload(InputStream) - Method in interface io.grpc.internal.Framer
Writes out a payload message.
writePayload(InputStream) - Method in class io.grpc.internal.MessageFramer
Writes out a payload message.
writeTrailers(Metadata, boolean, Status) - Method in interface io.grpc.internal.AbstractServerStream.Sink
Sends trailers to the remote end point.
A B C D E F G H I J K L M N O P R S T U V W 
Skip navigation links

Copyright © 2019. All rights reserved.