- ABORTED - Static variable in class io.grpc.Status
-
The operation was aborted, typically due to a concurrency issue like sequencer check failures,
transaction aborts, etc.
- AbstractClientStream - Class in io.grpc.internal
-
- AbstractClientStream(WritableBufferAllocator, StatsTraceContext, TransportTracer, Metadata, 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
-
- 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
-
- 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
-
- addCallback(ClientTransport.PingCallback, Executor) - Method in class io.grpc.internal.Http2Ping
-
Registers a callback that is invoked when the ping operation completes.
- addClientSocket(InternalInstrumented<InternalChannelz.SocketStats>) - Method in class io.grpc.InternalChannelz
-
Adds a socket.
- addListenSocket(InternalInstrumented<InternalChannelz.SocketStats>) - Method in class io.grpc.InternalChannelz
-
- addMethod(MethodDescriptor<ReqT, RespT>, ServerCallHandler<ReqT, RespT>) - Method in class io.grpc.ServerServiceDefinition.Builder
-
Add a method to be supported by the service.
- addMethod(ServerMethodDefinition<ReqT, RespT>) - Method in class io.grpc.ServerServiceDefinition.Builder
-
Add a method to be supported by the service.
- addMethod(MethodDescriptor<?, ?>) - Method in class io.grpc.ServiceDescriptor.Builder
-
Adds a method to this service.
- addOption(String, String) - Method in class io.grpc.InternalChannelz.SocketOptions.Builder
-
- addOption(String, int) - Method in class io.grpc.InternalChannelz.SocketOptions.Builder
-
- addOption(String, boolean) - Method in class io.grpc.InternalChannelz.SocketOptions.Builder
-
- addRootChannel(InternalInstrumented<InternalChannelz.ChannelStats>) - Method in class io.grpc.InternalChannelz
-
Adds a root channel.
- addServer(InternalInstrumented<InternalChannelz.ServerStats>) - Method in class io.grpc.InternalChannelz
-
Adds a server.
- addServerSocket(InternalInstrumented<InternalChannelz.ServerStats>, InternalInstrumented<InternalChannelz.SocketStats>) - Method in class io.grpc.InternalChannelz
-
Adds a server socket.
- 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.ServerBuilder
-
Adds a service implementation to the handler registry.
- addService(BindableService) - Method in class io.grpc.ServerBuilder
-
Adds a service implementation to the handler registry.
- 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
-
- addStreamTracerFactory(ServerStreamTracer.Factory) - Method in class io.grpc.ServerBuilder
-
- addSubchannel(InternalInstrumented<InternalChannelz.ChannelStats>) - Method in class io.grpc.InternalChannelz
-
Adds a subchannel.
- addTransportFilter(ServerTransportFilter) - Method in class io.grpc.internal.AbstractServerImplBuilder
-
- addTransportFilter(ServerTransportFilter) - Method in class io.grpc.ServerBuilder
-
- advmss - Variable in class io.grpc.InternalChannelz.TcpInfo
-
- allocate(int) - Method in interface io.grpc.internal.WritableBufferAllocator
-
- allocate(String) - Static method in class io.grpc.InternalLogId
-
- ALREADY_EXISTS - Static variable in class io.grpc.Status
-
Some entity that we attempted to create (e.g., file or directory) already exists.
- any - Variable in class io.grpc.InternalChannelz.OtherSecurity
-
- ApplicationThreadDeframer - Class in io.grpc.internal
-
- apply(Metadata) - Method in interface io.grpc.CallCredentials.MetadataApplier
-
Deprecated.
Called when headers are successfully generated.
- applyRequestMetadata(MethodDescriptor<?, ?>, Attributes, Executor, CallCredentials.MetadataApplier) - Method in interface io.grpc.CallCredentials
-
- applyRequestMetadata(CallCredentials.RequestInfo, Executor, CallCredentials2.MetadataApplier) - Method in class io.grpc.CallCredentials2
-
- applyRequestMetadata(MethodDescriptor<?, ?>, Attributes, Executor, CallCredentials.MetadataApplier) - Method in class io.grpc.CallCredentials2
-
- 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.
- ASCII_STRING_MARSHALLER - Static variable in class io.grpc.Metadata
-
Simple metadata marshaller that encodes strings as is.
- asException() - Method in class io.grpc.Status
-
- asException(Metadata) - Method in class io.grpc.Status
-
- asFactory() - Static method in class io.grpc.NameResolverProvider
-
- asRuntimeException() - Method in class io.grpc.Status
-
- asRuntimeException(Metadata) - Method in class io.grpc.Status
-
- ato - Variable in class io.grpc.InternalChannelz.TcpInfo
-
- 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_AUTHORITY - Static variable in interface io.grpc.CallCredentials
-
Deprecated.
- 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 interface io.grpc.CallCredentials
-
- ATTR_SECURITY_LEVEL - Static variable in class io.grpc.internal.GrpcAttributes
-
The security level of the transport.
- Attributes - Class in io.grpc
-
An immutable type-safe container of attributes.
- Attributes.Builder - Class in io.grpc
-
The helper class to build an Attributes instance.
- Attributes.Key<T> - Class in io.grpc
-
Key for an key-value pair.
- augmentDescription(String) - Method in class io.grpc.Status
-
Create a derived instance of
Status
augmenting the current description with
additional detail.
- authority() - Method in class io.grpc.Channel
-
The authority of the destination this channel connects to.
- 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.
- available() - Method in interface io.grpc.KnownLength
-
Returns the total number of bytes that can be read (or skipped over) from this object until all
bytes have been read out.
- awaitTermination(long, TimeUnit) - Method in class io.grpc.internal.ServerImpl
-
- awaitTermination() - Method in class io.grpc.internal.ServerImpl
-
- awaitTermination(long, TimeUnit) - Method in class io.grpc.ManagedChannel
-
Waits for the channel to become terminated, giving up if the timeout is reached.
- awaitTermination(long, TimeUnit) - Method in class io.grpc.Server
-
Waits for the server to become terminated, giving up if the timeout is reached.
- awaitTermination() - Method in class io.grpc.Server
-
Waits for the server to become terminated.
- CallCredentials - Interface in io.grpc
-
Carries credential data that will be propagated to the server via request metadata for each RPC.
- CallCredentials.MetadataApplier - Interface in io.grpc
-
Deprecated.
- CallCredentials.RequestInfo - Class in io.grpc
-
The request-related information passed to CallCredentials2.applyRequestMetadata()
.
- CallCredentials2 - Class in io.grpc
-
- CallCredentials2() - Constructor for class io.grpc.CallCredentials2
-
- CallCredentials2.MetadataApplier - Class in io.grpc
-
- CallOptions - Class in io.grpc
-
The collection of runtime options for a new RPC call.
- CallOptions.Key<T> - Class in io.grpc
-
Key for a key-value pair.
- callsFailed - Variable in class io.grpc.InternalChannelz.ChannelStats
-
- callsFailed - Variable in class io.grpc.InternalChannelz.ServerStats
-
- callsStarted - Variable in class io.grpc.InternalChannelz.ChannelStats
-
- callsStarted - Variable in class io.grpc.InternalChannelz.ServerStats
-
- callsSucceeded - Variable in class io.grpc.InternalChannelz.ChannelStats
-
- callsSucceeded - Variable in class io.grpc.InternalChannelz.ServerStats
-
- callTracerFactory - Variable in class io.grpc.internal.AbstractServerImplBuilder
-
- cancel(String, Throwable) - Method in class io.grpc.ClientCall
-
Prevent any further processing for this ClientCall
.
- 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.
- CANCELLED - Static variable in class io.grpc.Status
-
The operation was cancelled (typically by the caller).
- caState - Variable in class io.grpc.InternalChannelz.TcpInfo
-
- CensusStatsModule - Class in io.grpc.internal
-
Provides factories for
StreamTracer
that records stats to Census.
- CensusStatsModule(Tagger, TagContextBinarySerializer, StatsRecorder, Supplier<Stopwatch>, boolean) - Constructor for class io.grpc.internal.CensusStatsModule
-
- Channel - Class in io.grpc
-
A virtual connection to a conceptual endpoint, to perform RPCs.
- Channel() - Constructor for class io.grpc.Channel
-
- channelRef - Variable in class io.grpc.InternalChannelz.ChannelTrace.Event
-
- channels - Variable in class io.grpc.InternalChannelz.RootChannelList
-
- channelTrace - Variable in class io.grpc.InternalChannelz.ChannelStats
-
- channelz - Variable in class io.grpc.internal.AbstractServerImplBuilder
-
- 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.
- CheckedForwardingClientCall(ClientCall<ReqT, RespT>) - Constructor for class io.grpc.ClientInterceptors.CheckedForwardingClientCall
-
- checkedStart(ClientCall.Listener<RespT>, Metadata) - Method in class io.grpc.ClientInterceptors.CheckedForwardingClientCall
-
Subclasses implement the start logic here that would normally belong to start()
.
- checkReadable(int) - Method in class io.grpc.internal.AbstractReadableBuffer
-
- cipherSuiteStandardName - Variable in class io.grpc.InternalChannelz.Tls
-
- 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.
- ClientCall<ReqT,RespT> - Class in io.grpc
-
An instance of a call to a remote method.
- ClientCall() - Constructor for class io.grpc.ClientCall
-
- ClientCall.Listener<T> - Class in io.grpc
-
Callbacks for receiving metadata, response messages and completion status from the server.
- clientInboundHeaders() - Method in class io.grpc.internal.StatsTraceContext
-
- ClientInterceptor - Interface in io.grpc
-
Interface for intercepting outgoing calls before they are dispatched by a
Channel
.
- ClientInterceptors - Class in io.grpc
-
- ClientInterceptors.CheckedForwardingClientCall<ReqT,RespT> - Class in io.grpc
-
- ClientKeepAlivePinger(ConnectionClientTransport) - Constructor for class io.grpc.internal.KeepAliveManager.ClientKeepAlivePinger
-
- clientOutboundHeaders() - Method in class io.grpc.internal.StatsTraceContext
-
- clientSendsOneMessage() - Method in enum io.grpc.MethodDescriptor.MethodType
-
- 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.
- ClientStreamTracer - Class in io.grpc
-
- ClientStreamTracer() - Constructor for class io.grpc.ClientStreamTracer
-
- ClientStreamTracer.Factory - Class in io.grpc
-
- 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
-
- ClientTransportFactory - Interface in io.grpc.internal
-
- ClientTransportFactory.ClientTransportOptions - Class in io.grpc.internal
-
- 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.
- close(Status, Metadata) - Method in class io.grpc.ServerCall
-
Close the call with the provided status.
- 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.
- CODE_KEY - Static variable in class io.grpc.InternalStatus
-
Key to bind status code to trailing metadata.
- Codec - Interface in io.grpc
-
Encloses classes related to the compression and decompression of messages.
- Codec.Gzip - Class in io.grpc
-
A gzip compressor and decompressor.
- Codec.Identity - Class in io.grpc
-
The "identity", or "none" codec.
- 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
-
- CompositeReadableBuffer() - Constructor for class io.grpc.internal.CompositeReadableBuffer
-
- compress(OutputStream) - Method in class io.grpc.Codec.Gzip
-
- compress(OutputStream) - Method in class io.grpc.Codec.Identity
-
- compress(OutputStream) - Method in interface io.grpc.Compressor
-
Wraps an existing output stream with a compressing output stream.
- Compressor - Interface in io.grpc
-
Represents a message compressor.
- CompressorRegistry - Class in io.grpc
-
Encloses classes related to the compression and decompression of messages.
- compressorRegistry(CompressorRegistry) - Method in class io.grpc.ForwardingChannelBuilder
-
- compressorRegistry(CompressorRegistry) - Method in class io.grpc.internal.AbstractManagedChannelImplBuilder
-
- compressorRegistry(CompressorRegistry) - Method in class io.grpc.internal.AbstractServerImplBuilder
-
- compressorRegistry(CompressorRegistry) - Method in class io.grpc.ManagedChannelBuilder
-
Set the compression registry for use in the channel.
- compressorRegistry(CompressorRegistry) - Method in class io.grpc.ServerBuilder
-
Set the compression registry for use in the channel.
- ConnectionClientTransport - Interface in io.grpc.internal
-
- ConnectivityState - Enum in io.grpc
-
The connectivity states.
- ConnectivityStateInfo - Class in io.grpc
-
- containsClientSocket(InternalLogId) - Method in class io.grpc.InternalChannelz
-
- containsKey(Metadata.Key<?>) - Method in class io.grpc.Metadata
-
Returns true if a value is defined for the given key.
- containsServer(InternalLogId) - Method in class io.grpc.InternalChannelz
-
- containsSubchannel(InternalLogId) - Method in class io.grpc.InternalChannelz
-
- 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
-
- 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
-
- Contexts - Class in io.grpc
-
Utility methods for working with
Context
s in GRPC.
- copy(InputStream, OutputStream) - Static method in class io.grpc.internal.IoUtils
-
Copies the data from input stream to output stream.
- create(String) - Static method in class io.grpc.Attributes.Key
-
- create(String) - Static method in class io.grpc.CallOptions.Key
-
- 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
-
- create(MethodDescriptor.MethodType, String, MethodDescriptor.Marshaller<RequestT>, MethodDescriptor.Marshaller<ResponseT>) - Static method in class io.grpc.MethodDescriptor
-
- create(MethodDescriptor<ReqT, RespT>, ServerCallHandler<ReqT, RespT>) - Static method in class io.grpc.ServerMethodDefinition
-
Create a new instance.
- createOobChannel(EquivalentAddressGroup, String) - Method in class io.grpc.LoadBalancer.Helper
-
Out-of-band channel for LoadBalancer’s own RPC needs, e.g., talking to an external
load-balancer service.
- createOobChannel(EquivalentAddressGroup, String) - Method in class io.grpc.util.ForwardingLoadBalancerHelper
-
- createSubchannel(EquivalentAddressGroup, Attributes) - Method in class io.grpc.LoadBalancer.Helper
-
Creates a Subchannel, which is a logical connection to the given group of addresses which are
considered equivalent.
- createSubchannel(List<EquivalentAddressGroup>, Attributes) - Method in class io.grpc.LoadBalancer.Helper
-
Creates a Subchannel, which is a logical connection to the given group of addresses which are
considered equivalent.
- createSubchannel(EquivalentAddressGroup, Attributes) - Method in class io.grpc.util.ForwardingLoadBalancerHelper
-
- createSubchannel(List<EquivalentAddressGroup>, Attributes) - Method in class io.grpc.util.ForwardingLoadBalancerHelper
-
- createWithDefault(String, T) - Static method in class io.grpc.CallOptions.Key
-
- creationTimeNanos - Variable in class io.grpc.InternalChannelz.ChannelTrace
-
- currentTimeNanos() - Method in interface io.grpc.internal.TimeProvider
-
Returns the current nano time.
- data - Variable in class io.grpc.InternalChannelz.SocketStats
-
- DATA_LOSS - Static variable in class io.grpc.Status
-
Unrecoverable data loss or corruption.
- DEADLINE_EXCEEDED - Static variable in class io.grpc.Status
-
Deadline expired before operation could complete.
- decompress(InputStream) - Method in class io.grpc.Codec.Gzip
-
- decompress(InputStream) - Method in class io.grpc.Codec.Identity
-
- decompress(InputStream) - Method in interface io.grpc.Decompressor
-
Wraps an existing input stream with a decompressing input stream.
- Decompressor - Interface in io.grpc
-
Represents a message decompressor.
- DecompressorRegistry - Class in io.grpc
-
Encloses classes related to the compression and decompression of messages.
- decompressorRegistry(DecompressorRegistry) - Method in class io.grpc.ForwardingChannelBuilder
-
- decompressorRegistry(DecompressorRegistry) - Method in class io.grpc.internal.AbstractManagedChannelImplBuilder
-
- decompressorRegistry(DecompressorRegistry) - Method in class io.grpc.internal.AbstractServerImplBuilder
-
- decompressorRegistry(DecompressorRegistry) - Method in class io.grpc.ManagedChannelBuilder
-
Set the decompression registry for use in the channel.
- decompressorRegistry(DecompressorRegistry) - Method in class io.grpc.ServerBuilder
-
Set the decompression registry for use in the channel.
- DEFAULT - Static variable in class io.grpc.CallOptions
-
A blank CallOptions
that all fields are not set.
- DEFAULT_KEEPALIVE_TIME_NANOS - Static variable in class io.grpc.internal.GrpcUtil
-
The default delay in nanos before we send a keepalive.
- DEFAULT_KEEPALIVE_TIMEOUT_NANOS - Static variable in class io.grpc.internal.GrpcUtil
-
The default timeout in nanos for a keepalive ping request.
- 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
-
- 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.
- 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
-
- 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.ClientInterceptors.CheckedForwardingClientCall
-
- delegate() - Method in class io.grpc.ForwardingChannelBuilder
-
Returns the delegated ManagedChannelBuilder
.
- delegate() - Method in class io.grpc.ForwardingClientCall
-
Returns the delegated ClientCall
.
- delegate() - Method in class io.grpc.ForwardingClientCall.SimpleForwardingClientCall
-
- delegate() - Method in class io.grpc.ForwardingClientCallListener
-
Returns the delegated ClientCall.Listener
.
- delegate() - Method in class io.grpc.ForwardingClientCallListener.SimpleForwardingClientCallListener
-
- delegate() - Method in class io.grpc.ForwardingServerCall
-
Returns the delegated ServerCall
.
- delegate() - Method in class io.grpc.ForwardingServerCall.SimpleForwardingServerCall
-
- delegate() - Method in class io.grpc.ForwardingServerCallListener
-
Returns the delegated ServerCall.Listener
.
- delegate() - Method in class io.grpc.ForwardingServerCallListener.SimpleForwardingServerCallListener
-
- delegate() - Method in class io.grpc.util.ForwardingLoadBalancerHelper
-
Returns the underlying helper.
- 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.
- description - Variable in class io.grpc.InternalChannelz.ChannelTrace.Event
-
- directExecutor() - Method in class io.grpc.ForwardingChannelBuilder
-
- directExecutor() - Method in class io.grpc.internal.AbstractManagedChannelImplBuilder
-
- directExecutor() - Method in class io.grpc.internal.AbstractServerImplBuilder
-
- directExecutor() - Method in class io.grpc.ManagedChannelBuilder
-
Execute application code directly in the transport thread.
- directExecutor() - Method in class io.grpc.ServerBuilder
-
Execute application code directly in the transport thread.
- disableRetry() - Method in class io.grpc.ForwardingChannelBuilder
-
- disableRetry() - Method in class io.grpc.internal.AbstractManagedChannelImplBuilder
-
- disableRetry() - Method in class io.grpc.ManagedChannelBuilder
-
Disables the retry and hedging mechanism provided by the gRPC library.
- discardAll(Metadata.Key<T>) - Method in class io.grpc.Metadata
-
Remove all values for the given key without returning them.
- 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
-
- DnsNameResolverProvider() - Constructor for class io.grpc.internal.DnsNameResolverProvider
-
- Drainable - Interface in io.grpc
-
- drainTo(OutputStream) - Method in interface io.grpc.Drainable
-
Transfers the entire contents of this stream to the specified target.
- fackets - Variable in class io.grpc.InternalChannelz.TcpInfo
-
- Factory() - Constructor for class io.grpc.ClientStreamTracer.Factory
-
- Factory(TimeProvider) - Constructor for class io.grpc.internal.TransportTracer.Factory
-
- Factory() - Constructor for class io.grpc.LoadBalancer.Factory
-
- Factory() - Constructor for class io.grpc.NameResolver.Factory
-
- Factory() - Constructor for class io.grpc.ServerStreamTracer.Factory
-
- fail(Status) - Method in interface io.grpc.CallCredentials.MetadataApplier
-
Deprecated.
Called when there has been an error when preparing the headers.
- failed(Throwable) - Method in class io.grpc.internal.Http2Ping
-
Completes this operation exceptionally.
- FAILED_PRECONDITION - Static variable in class io.grpc.Status
-
Operation was rejected because the system is not in a state required for the operation's
execution.
- FailingClientStream - Class in io.grpc.internal
-
- 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
-
- fallbackHandlerRegistry(HandlerRegistry) - Method in class io.grpc.ServerBuilder
-
Sets a fallback handler registry that will be looked up in if a method is not found in the
primary registry.
- fillInStackTrace() - Method in exception io.grpc.StatusException
-
- fillInStackTrace() - Method in exception io.grpc.StatusRuntimeException
-
- filterContext(Context) - Method in class io.grpc.ServerStreamTracer
-
Called before the interceptors and the call handlers and make changes to the Context object
if needed.
- 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.ForwardingChannelBuilder
-
This method serves to force sub classes to "hide" this static factory.
- forAddress(String, int) - Static method in class io.grpc.inprocess.InProcessChannelBuilder
-
Always fails.
- forAddress(String, int) - Static method in class io.grpc.internal.AbstractManagedChannelImplBuilder
-
- forAddress(String, int) - Static method in class io.grpc.ManagedChannelBuilder
-
Creates a channel with the target's address and port number.
- 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.
- forNonError(ConnectivityState) - Static method in class io.grpc.ConnectivityStateInfo
-
Returns an instance for a state that is not TRANSIENT_FAILURE
.
- forPort(int) - Static method in class io.grpc.inprocess.InProcessServerBuilder
-
Always fails.
- forPort(int) - Static method in class io.grpc.internal.AbstractServerImplBuilder
-
- forPort(int) - Static method in class io.grpc.ServerBuilder
-
Static factory for creating a new ServerBuilder.
- forResource(SharedResourceHolder.Resource<T>) - Static method in class io.grpc.internal.SharedResourcePool
-
- forTarget(String) - Static method in class io.grpc.ForwardingChannelBuilder
-
This method serves to force sub classes to "hide" this static factory.
- forTarget(String) - Static method in class io.grpc.inprocess.InProcessChannelBuilder
-
Always fails.
- forTarget(String) - Static method in class io.grpc.internal.AbstractManagedChannelImplBuilder
-
- forTarget(String) - Static method in class io.grpc.ManagedChannelBuilder
-
Creates a channel with a target string, which can be either a valid
NameResolver
-compliant URI, or an authority string.
- forTransientFailure(Status) - Static method in class io.grpc.ConnectivityStateInfo
-
Returns an instance for TRANSIENT_FAILURE
, associated with an error status.
- ForwardingChannelBuilder<T extends ForwardingChannelBuilder<T>> - Class in io.grpc
-
- ForwardingChannelBuilder() - Constructor for class io.grpc.ForwardingChannelBuilder
-
The default constructor.
- ForwardingClientCall<ReqT,RespT> - Class in io.grpc
-
- ForwardingClientCall() - Constructor for class io.grpc.ForwardingClientCall
-
- ForwardingClientCall.SimpleForwardingClientCall<ReqT,RespT> - Class in io.grpc
-
- ForwardingClientCallListener<RespT> - Class in io.grpc
-
- ForwardingClientCallListener() - Constructor for class io.grpc.ForwardingClientCallListener
-
- ForwardingClientCallListener.SimpleForwardingClientCallListener<RespT> - Class in io.grpc
-
- ForwardingLoadBalancerHelper - Class in io.grpc.util
-
- ForwardingLoadBalancerHelper() - Constructor for class io.grpc.util.ForwardingLoadBalancerHelper
-
- ForwardingReadableBuffer - Class in io.grpc.internal
-
- ForwardingReadableBuffer(ReadableBuffer) - Constructor for class io.grpc.internal.ForwardingReadableBuffer
-
Constructor.
- ForwardingServerCall<ReqT,RespT> - Class in io.grpc
-
- ForwardingServerCall() - Constructor for class io.grpc.ForwardingServerCall
-
- ForwardingServerCall.SimpleForwardingServerCall<ReqT,RespT> - Class in io.grpc
-
- ForwardingServerCallListener<ReqT> - Class in io.grpc
-
- ForwardingServerCallListener() - Constructor for class io.grpc.ForwardingServerCallListener
-
- ForwardingServerCallListener.SimpleForwardingServerCallListener<ReqT> - Class in io.grpc
-
- 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.
- fromCode(Status.Code) - Static method in class io.grpc.Status
-
- fromCodeValue(int) - Static method in class io.grpc.Status
-
- fromThrowable(Throwable) - Static method in class io.grpc.Status
-
- generateFullMethodName(String, String) - Static method in class io.grpc.MethodDescriptor
-
Generate the fully qualified method name.
- generateName() - Static method in class io.grpc.inprocess.InProcessServerBuilder
-
Generates a new server name that is unique each time.
- geRawMethodName(MethodDescriptor<?, ?>) - Method in class io.grpc.InternalMethodDescriptor
-
- get(Attributes.Key<T>) - Method in class io.grpc.Attributes
-
Gets the value for the key, or null
if it's not present.
- 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.
- get(Metadata.Key<T>) - Method in class io.grpc.Metadata
-
Returns the last metadata entry added with the name 'name' parsed as T.
- getAddresses() - Method in class io.grpc.EquivalentAddressGroup
-
Returns an immutable list of the addresses.
- getAddresses() - Method in class io.grpc.LoadBalancer.Subchannel
-
Returns the addresses that this Subchannel is bound to.
- getAdvertisedMessageEncodings() - Method in class io.grpc.DecompressorRegistry
-
Provides a list of all message encodings that have decompressors available and should be
advertised.
- getAll(Metadata.Key<T>) - Method in class io.grpc.Metadata
-
Returns all the metadata entries named 'name', in the order they were received, parsed as T, or
null if there are none.
- getAllAddresses() - Method in class io.grpc.LoadBalancer.Subchannel
-
Returns the addresses that this Subchannel is bound to.
- getAttributes() - Method in class io.grpc.ClientCall
-
Returns additional properties of the call.
- getAttributes() - Method in class io.grpc.EquivalentAddressGroup
-
Returns the attributes.
- 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.LoadBalancer.Subchannel
-
- getAttributes() - Method in class io.grpc.ServerCall
-
Returns properties of a single call.
- getAttributes() - Method in class io.grpc.ServerStreamTracer.ServerCallInfo
-
- getAuthority() - Method in class io.grpc.CallCredentials.RequestInfo
-
Returns the authority string used to authenticate the server for this call.
- getAuthority() - Method in class io.grpc.CallOptions
-
Override the HTTP/2 authority the channel claims to be connecting to.
- 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.LoadBalancer.Helper
-
Returns the authority string of the channel, which is derived from the DNS-style target name.
- getAuthority() - Method in class io.grpc.ServerCall
-
Gets the authority this call is addressed to.
- getAuthority() - Method in class io.grpc.ServerStreamTracer.ServerCallInfo
-
- getAuthority() - Method in class io.grpc.util.ForwardingLoadBalancerHelper
-
- getCallOptions() - Method in class io.grpc.LoadBalancer.PickSubchannelArgs
-
Call options.
- getCandidatesViaHardCoded(Class<T>, Iterable<Class<?>>) - Static method in class io.grpc.InternalServiceProviders
-
Accessor for method.
- getCandidatesViaServiceLoader(Class<T>, ClassLoader) - Static method in class io.grpc.InternalServiceProviders
-
Accessor for method.
- getCause() - Method in class io.grpc.Status
-
The underlying cause of an error.
- getChannel(long) - Method in class io.grpc.InternalChannelz
-
Returns a channel.
- getCode() - Method in class io.grpc.Status
-
The canonical status code.
- getCompressor() - Method in class io.grpc.CallOptions
-
Returns the compressor's name.
- getCredentials() - Method in class io.grpc.CallOptions
-
Returns the call credentials.
- getDeadline() - Method in class io.grpc.CallOptions
-
Returns the deadline or null
if the deadline is not set.
- getDefault() - Method in class io.grpc.CallOptions.Key
-
Returns the user supplied default value for this key.
- getDefaultFactory() - Static method in class io.grpc.internal.TransportTracer
-
- getDefaultInstance() - Static method in class io.grpc.CompressorRegistry
-
Returns the default instance used by gRPC when the registry is not specified.
- getDefaultInstance() - Static method in class io.grpc.DecompressorRegistry
-
- 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
-
- getDefaultScheme() - Method in class io.grpc.NameResolver.Factory
-
- getDescription() - Method in class io.grpc.Status
-
A description of this status for human consumption.
- getEagAttributes() - Method in class io.grpc.internal.ClientTransportFactory.ClientTransportOptions
-
- getExecutor() - Method in class io.grpc.CallOptions
-
- getFullMethodName() - Method in class io.grpc.MethodDescriptor
-
The fully qualified name of the method.
- getGrpcUserAgent(String, String) - Static method in class io.grpc.internal.GrpcUtil
-
Gets the User-Agent string for the gRPC transport.
- getHeaders() - Method in class io.grpc.LoadBalancer.PickSubchannelArgs
-
Headers of the call.
- getHost(InetSocketAddress) - Static method in class io.grpc.internal.GrpcUtil
-
- getId() - Method in class io.grpc.InternalLogId
-
- getImmutableServices() - Method in class io.grpc.internal.ServerImpl
-
- getImmutableServices() - Method in class io.grpc.Server
-
Returns immutable services registered with the server, or an empty list if not supported by the
implementation.
- getInstance() - Static method in class io.grpc.PickFirstBalancerFactory
-
Gets an instance of this factory.
- getInstance() - Static method in class io.grpc.util.RoundRobinLoadBalancerFactory
-
Gets the singleton instance of this factory.
- getKnownMessageEncodings() - Method in class io.grpc.DecompressorRegistry
-
Provides a list of all message encodings that have decompressors available.
- getListenSockets() - Method in interface io.grpc.internal.InternalServer
-
Returns the listen sockets of this server.
- getLoadBalancingPolicyFromServiceConfig(Map<String, Object>) - Static method in class io.grpc.internal.ServiceConfigUtil
-
Extracts the load balancing policy from a service config, or null
.
- getLogId() - Method in class io.grpc.internal.ServerImpl
-
- getLogId() - Method in interface io.grpc.InternalWithLogId
-
Returns an ID that is primarily used in debug logs.
- getMaxInboundMessageSize() - Method in class io.grpc.CallOptions
-
Gets the maximum allowed message size acceptable from the remote peer.
- getMaxOutboundMessageSize() - Method in class io.grpc.CallOptions
-
Gets the maximum allowed message size acceptable to send the remote peer.
- getMessageClass() - Method in interface io.grpc.MethodDescriptor.ReflectableMarshaller
-
Returns the Class
that this marshaller serializes and deserializes.
- getMessageEncoding() - Method in class io.grpc.Codec.Gzip
-
- getMessageEncoding() - Method in class io.grpc.Codec.Identity
-
- getMessageEncoding() - Method in interface io.grpc.Compressor
-
Returns the message encoding that this compressor uses.
- getMessageEncoding() - Method in interface io.grpc.Decompressor
-
Returns the message encoding that this compressor uses.
- getMessagePrototype() - Method in interface io.grpc.MethodDescriptor.PrototypeMarshaller
-
An instance of the expected message type, typically used as a schema and helper for producing
other message instances.
- getMethod(String) - Method in class io.grpc.ServerServiceDefinition
-
Look up a method by its fully qualified name.
- getMethodDescriptor() - Method in class io.grpc.CallCredentials.RequestInfo
-
The method descriptor of this RPC.
- getMethodDescriptor() - Method in class io.grpc.ForwardingServerCall.SimpleForwardingServerCall
-
- getMethodDescriptor() - Method in class io.grpc.LoadBalancer.PickSubchannelArgs
-
Call method.
- getMethodDescriptor() - Method in class io.grpc.ServerCall
-
- getMethodDescriptor() - Method in class io.grpc.ServerMethodDefinition
-
The MethodDescriptor
for this method.
- getMethodDescriptor() - Method in class io.grpc.ServerStreamTracer.ServerCallInfo
-
- getMethods() - Method in class io.grpc.ServerServiceDefinition
-
Gets all the methods of service.
- getMethods() - Method in class io.grpc.ServiceDescriptor
-
A collection of
MethodDescriptor
instances describing the methods exposed by the
service.
- getMutableServices() - Method in class io.grpc.internal.ServerImpl
-
- getMutableServices() - Method in class io.grpc.Server
-
Returns mutable services registered with the server, or an empty list if not supported by the
implementation.
- getName() - Method in class io.grpc.inprocess.InProcessSocketAddress
-
Gets the name of the inprocess channel or server.
- getName() - Method in class io.grpc.ServiceDescriptor
-
Simple name of the service.
- getNameResolverFactory() - Method in class io.grpc.LoadBalancer.Helper
-
Returns the NameResolver of the channel.
- getNameResolverFactory() - Method in class io.grpc.util.ForwardingLoadBalancerHelper
-
- getNameResolverParams() - Method in class io.grpc.internal.AbstractManagedChannelImplBuilder
-
Subclasses can override this method to provide additional parameters to NameResolver.Factory#newNameResolver
.
- 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
-
- getOption(CallOptions.Key<T>) - Method in class io.grpc.CallOptions
-
Get the value for a custom option or its inherent default.
- getPort() - Method in interface io.grpc.internal.InternalServer
-
Returns what underlying port the server is listening on, or -1 if the port number is not
available or does not make sense.
- getPort() - Method in class io.grpc.internal.ServerImpl
-
- getPort() - Method in class io.grpc.Server
-
Returns the port number the server is listening on.
- getProxyParameters() - Method in class io.grpc.internal.ClientTransportFactory.ClientTransportOptions
-
- getRawAdvertisedMessageEncodings(DecompressorRegistry) - Static method in class io.grpc.InternalDecompressorRegistry
-
- getRequestMarshaller() - Method in class io.grpc.MethodDescriptor
-
Returns the marshaller for the request type.
- getResponseMarshaller() - Method in class io.grpc.MethodDescriptor
-
Returns the marshaller for the response type.
- getRootChannel(long) - Method in class io.grpc.InternalChannelz
-
- getRootChannels(long, int) - Method in class io.grpc.InternalChannelz
-
- 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.
- getSchemaDescriptor() - Method in class io.grpc.MethodDescriptor
-
Returns the schema descriptor for this method.
- getSchemaDescriptor() - Method in class io.grpc.ServiceDescriptor
-
Returns the schema descriptor for this service.
- getSecurityLevel() - Method in class io.grpc.CallCredentials.RequestInfo
-
The security level on the transport.
- getServerCallHandler() - Method in class io.grpc.ServerMethodDefinition
-
Handler for incoming calls.
- getServers(long, int) - Method in class io.grpc.InternalChannelz
-
Returns a server list.
- getServerSockets(long, long, int) - Method in class io.grpc.InternalChannelz
-
Returns socket refs for a server.
- getServiceAuthority() - Method in class io.grpc.NameResolver
-
Returns the authority used to authenticate connections to servers.
- getServiceDescriptor() - Method in class io.grpc.ServerServiceDefinition
-
The descriptor for the service.
- getServices() - Method in class io.grpc.HandlerRegistry
-
Returns the
ServerServiceDefinition
s provided by the registry, or an empty list if not
supported by the implementation.
- getServices() - Method in class io.grpc.internal.ServerImpl
-
- getServices() - Method in class io.grpc.Server
-
Returns all services registered with the server, or an empty list if not supported by the
implementation.
- getServices() - Method in class io.grpc.util.MutableHandlerRegistry
-
Note: This does not necessarily return a consistent view of the map.
- getSocket(long) - Method in class io.grpc.InternalChannelz
-
Returns a socket.
- getState() - Method in class io.grpc.ConnectivityStateInfo
-
Returns the state.
- getState() - Method in class io.grpc.internal.AtomicBackoff
-
Returns the current state.
- getState(boolean) - Method in class io.grpc.ManagedChannel
-
Gets the current connectivity 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.
- getStats() - Method in interface io.grpc.InternalInstrumented
-
Returns the stats object.
- getStatsTraceContext() - Method in class io.grpc.internal.AbstractStream.TransportState
-
- getStatus() - Method in class io.grpc.ConnectivityStateInfo
-
Returns the status associated with the state.
- getStatus() - Method in class io.grpc.LoadBalancer.PickResult
-
The status associated with this result.
- getStatus() - Method in exception io.grpc.StatusException
-
Returns the status code as a
Status
object.
- getStatus() - Method in exception io.grpc.StatusRuntimeException
-
Returns the status code as a
Status
object.
- getStickinessMetadataKeyFromServiceConfig(Map<String, Object>) - Static method in class io.grpc.internal.ServiceConfigUtil
-
Extracts the stickiness metadata key from a service config, or null
.
- getStreamTracerFactories() - Method in class io.grpc.CallOptions
-
Returns an immutable list of ClientStreamTracerFactory
s.
- getStreamTracerFactory() - Method in class io.grpc.LoadBalancer.PickResult
-
The stream tracer factory this result was created with.
- getSubchannel(long) - Method in class io.grpc.InternalChannelz
-
Returns a subchannel.
- getSubchannel() - Method in class io.grpc.LoadBalancer.PickResult
-
The Subchannel if this result was created by
withSubchannel()
, or
null otherwise.
- getTag() - Method in class io.grpc.InternalLogId
-
- getThreadFactory(String, boolean) - Static method in class io.grpc.internal.GrpcUtil
-
- getTracersForTest() - Method in class io.grpc.internal.StatsTraceContext
-
Returns a copy of the tracer list.
- getTrailers() - Method in exception io.grpc.StatusException
-
Returns the received trailers.
- getTrailers() - Method in exception io.grpc.StatusRuntimeException
-
Returns the received trailers.
- getTransportAttrs() - Method in class io.grpc.CallCredentials.RequestInfo
-
Returns the transport attributes.
- getTransportTracer() - Method in class io.grpc.internal.AbstractClientStream
-
- getTransportTracer() - Method in class io.grpc.internal.AbstractStream.TransportState
-
- getType() - Method in class io.grpc.MethodDescriptor
-
The call type of the method.
- getUserAgent() - Method in class io.grpc.internal.ClientTransportFactory.ClientTransportOptions
-
- Grpc - Class in io.grpc
-
Stuff that are part of the public API but are not bound to particular classes, e.g., static
methods, constants, attribute and context keys.
- Grpc.TransportAttr - Annotation Type in io.grpc
-
Annotation for transport attributes.
- 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.
- Gzip() - Constructor for class io.grpc.Codec.Gzip
-
- id(InternalWithLogId) - Static method in class io.grpc.InternalChannelz
-
- idleTimeout(long, TimeUnit) - Method in class io.grpc.ForwardingChannelBuilder
-
- idleTimeout(long, TimeUnit) - Method in class io.grpc.internal.AbstractManagedChannelImplBuilder
-
- idleTimeout(long, TimeUnit) - Method in class io.grpc.ManagedChannelBuilder
-
Set the duration without ongoing RPCs before going to idle mode.
- ignoreClose(ReadableBuffer) - Static method in class io.grpc.internal.ReadableBuffers
-
- 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.ClientStreamTracer
-
Headers has been received from the server.
- 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.StreamTracer
-
An inbound message has been received by the stream.
- inboundMessageRead(int, long, long) - Method in class io.grpc.internal.StatsTraceContext
-
- inboundMessageRead(int, long, long) - Method in class io.grpc.StreamTracer
-
An inbound message has been fully read from the transport.
- 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.StreamTracer
-
The uncompressed size of some inbound data is revealed.
- inboundWireSize(long) - Method in class io.grpc.internal.StatsTraceContext
-
- inboundWireSize(long) - Method in class io.grpc.StreamTracer
-
The wire size of some inbound data is revealed.
- 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
-
- InProcessSocketAddress(String) - Constructor for class io.grpc.inprocess.InProcessSocketAddress
-
- INSTANCE - Static variable in class io.grpc.internal.NoopClientStream
-
- instance() - Static method in class io.grpc.InternalChannelz
-
- instance() - Static method in class io.grpc.util.TransmitStatusRuntimeExceptionInterceptor
-
- intercept(Channel, ClientInterceptor...) - Static method in class io.grpc.ClientInterceptors
-
Create a new
Channel
that will call
interceptors
before starting a call on the
given channel.
- intercept(Channel, List<? extends ClientInterceptor>) - Static method in class io.grpc.ClientInterceptors
-
Create a new
Channel
that will call
interceptors
before starting a call on the
given channel.
- intercept(List<ClientInterceptor>) - Method in class io.grpc.ForwardingChannelBuilder
-
- intercept(ClientInterceptor...) - Method in class io.grpc.ForwardingChannelBuilder
-
- 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
-
- intercept(List<ClientInterceptor>) - Method in class io.grpc.ManagedChannelBuilder
-
Adds interceptors that will be called before the channel performs its real work.
- intercept(ClientInterceptor...) - Method in class io.grpc.ManagedChannelBuilder
-
Adds interceptors that will be called before the channel performs its real work.
- intercept(ServerInterceptor) - Method in class io.grpc.ServerBuilder
-
- intercept(ServerServiceDefinition, ServerInterceptor...) - Static method in class io.grpc.ServerInterceptors
-
Create a new
ServerServiceDefinition
whose
ServerCallHandler
s will call
interceptors
before calling the pre-existing
ServerCallHandler
.
- intercept(BindableService, ServerInterceptor...) - Static method in class io.grpc.ServerInterceptors
-
- intercept(ServerServiceDefinition, List<? extends ServerInterceptor>) - Static method in class io.grpc.ServerInterceptors
-
Create a new
ServerServiceDefinition
whose
ServerCallHandler
s will call
interceptors
before calling the pre-existing
ServerCallHandler
.
- intercept(BindableService, List<? extends ServerInterceptor>) - Static method in class io.grpc.ServerInterceptors
-
- interceptCall(MethodDescriptor<ReqT, RespT>, CallOptions, Channel) - Method in interface io.grpc.ClientInterceptor
-
- interceptCall(Context, ServerCall<ReqT, RespT>, Metadata, ServerCallHandler<ReqT, RespT>) - Static method in class io.grpc.Contexts
-
Make the provided
Context
Context.current()
for the creation of a listener
to a received call and for all events received by that listener.
- interceptCall(ServerCall<ReqT, RespT>, Metadata, ServerCallHandler<ReqT, RespT>) - Method in interface io.grpc.ServerInterceptor
-
- interceptCall(ServerCall<ReqT, RespT>, Metadata, ServerCallHandler<ReqT, RespT>) - Method in class io.grpc.util.TransmitStatusRuntimeExceptionInterceptor
-
- interceptCallHandler(ServerInterceptor, ServerCallHandler<ReqT, RespT>) - Static method in class io.grpc.InternalServerInterceptors
-
- interceptCallHandlerCreate(ServerInterceptor, ServerCallHandler<ReqT, RespT>) - Static method in class io.grpc.InternalServerInterceptors
-
- interceptForward(Channel, ClientInterceptor...) - Static method in class io.grpc.ClientInterceptors
-
Create a new
Channel
that will call
interceptors
before starting a call on the
given channel.
- interceptForward(Channel, List<? extends ClientInterceptor>) - Static method in class io.grpc.ClientInterceptors
-
Create a new
Channel
that will call
interceptors
before starting a call on the
given channel.
- interceptForward(ServerServiceDefinition, ServerInterceptor...) - Static method in class io.grpc.ServerInterceptors
-
Create a new
ServerServiceDefinition
whose
ServerCallHandler
s will call
interceptors
before calling the pre-existing
ServerCallHandler
.
- interceptForward(BindableService, ServerInterceptor...) - Static method in class io.grpc.ServerInterceptors
-
- interceptForward(ServerServiceDefinition, List<? extends ServerInterceptor>) - Static method in class io.grpc.ServerInterceptors
-
Create a new
ServerServiceDefinition
whose
ServerCallHandler
s will call
interceptors
before calling the pre-existing
ServerCallHandler
.
- interceptForward(BindableService, List<? extends ServerInterceptor>) - Static method in class io.grpc.ServerInterceptors
-
- Internal - Annotation Type in io.grpc
-
Annotates a program element (class, method, package, etc) which is internal to gRPC, not part of
the public API, and should not be used by users of gRPC.
- INTERNAL - Static variable in class io.grpc.Status
-
Internal errors.
- InternalChannelz - Class in io.grpc
-
This is an internal API.
- InternalChannelz() - Constructor for class io.grpc.InternalChannelz
-
- InternalChannelz.ChannelStats - Class in io.grpc
-
A data class to represent a channel's stats.
- InternalChannelz.ChannelStats.Builder - Class in io.grpc
-
- InternalChannelz.ChannelTrace - Class in io.grpc
-
- InternalChannelz.ChannelTrace.Builder - Class in io.grpc
-
- InternalChannelz.ChannelTrace.Event - Class in io.grpc
-
- InternalChannelz.ChannelTrace.Event.Builder - Class in io.grpc
-
- InternalChannelz.ChannelTrace.Event.Severity - Enum in io.grpc
-
- InternalChannelz.OtherSecurity - Class in io.grpc
-
- InternalChannelz.RootChannelList - Class in io.grpc
-
- InternalChannelz.Security - Class in io.grpc
-
- InternalChannelz.ServerList - Class in io.grpc
-
- InternalChannelz.ServerSocketsList - Class in io.grpc
-
- InternalChannelz.ServerStats - Class in io.grpc
-
- InternalChannelz.ServerStats.Builder - Class in io.grpc
-
- InternalChannelz.SocketOptions - Class in io.grpc
-
- InternalChannelz.SocketOptions.Builder - Class in io.grpc
-
- InternalChannelz.SocketStats - Class in io.grpc
-
- InternalChannelz.TcpInfo - Class in io.grpc
-
- InternalChannelz.TcpInfo.Builder - Class in io.grpc
-
- InternalChannelz.Tls - Class in io.grpc
-
- InternalChannelz.TransportStats - Class in io.grpc
-
A data class to represent transport stats.
- InternalClientInterceptors - Class in io.grpc
-
Internal accessor.
- InternalClientInterceptors() - Constructor for class io.grpc.InternalClientInterceptors
-
- InternalDecompressorRegistry - Class in io.grpc
-
Private accessor for decompressor registries.
- InternalInstrumented<T> - Interface in io.grpc
-
An internal class.
- InternalKnownTransport - Enum in io.grpc
-
All known transports.
- InternalLogId - Class in io.grpc
-
An internal class.
- InternalLogId(String, long) - Constructor for class io.grpc.InternalLogId
-
- InternalManagedChannelProvider - Class in io.grpc
-
- InternalManagedChannelProvider() - Constructor for class io.grpc.InternalManagedChannelProvider
-
- InternalMetadata - Class in io.grpc
-
- InternalMetadata() - Constructor for class io.grpc.InternalMetadata
-
- InternalMetadata.TrustedAsciiMarshaller<T> - Interface in io.grpc
-
A specialized plain ASCII marshaller.
- InternalMethodDescriptor - Class in io.grpc
-
Accesses internal data and methods.
- InternalMethodDescriptor(InternalKnownTransport) - Constructor for class io.grpc.InternalMethodDescriptor
-
- InternalNotifyOnServerBuild - Interface in io.grpc
-
Provides a callback method for a service to receive a reference to its server.
- InternalServer - Interface in io.grpc.internal
-
An object that accepts new incoming connections.
- InternalServerInterceptors - Class in io.grpc
-
- InternalServiceProviders - Class in io.grpc
-
- InternalServiceProviders.PriorityAccessor<T> - Interface in io.grpc
-
- InternalStatus - Class in io.grpc
-
Accesses internal data.
- InternalWithLogId - Interface in io.grpc
-
An internal class.
- INVALID_ARGUMENT - Static variable in class io.grpc.Status
-
Client specified an invalid argument.
- io.grpc - package io.grpc
-
The gRPC core public API.
- 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.
- IoUtils - Class in io.grpc.internal
-
Common IoUtils for thrift and nanopb to convert inputstream to bytes.
- IoUtils() - Constructor for class io.grpc.internal.IoUtils
-
- IS_RESTRICTED_APPENGINE - Static variable in class io.grpc.internal.GrpcUtil
-
- isAndroid(ClassLoader) - Static method in class io.grpc.InternalServiceProviders
-
Accessor for ServiceProviders.isAndroid(java.lang.ClassLoader)
.
- isAvailable() - Method in class io.grpc.internal.DnsNameResolverProvider
-
- isAvailable() - Method in class io.grpc.ManagedChannelProvider
-
Whether this provider is available for use, taking the current environment into consideration.
- isAvailable() - Method in class io.grpc.NameResolverProvider
-
Whether this provider is available for use, taking the current environment into consideration.
- isAvailable() - Method in class io.grpc.ServerProvider
-
Whether this provider is available for use, taking the current environment into consideration.
- isCancelled() - Method in class io.grpc.ServerCall
-
Returns true
when the call is cancelled and the server is encouraged to abort
processing to save resources, since the client will not be processing any further methods.
- 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
-
- isDrop() - Method in class io.grpc.LoadBalancer.PickResult
-
Returns
true
if this result was created by
withDrop()
.
- isGrpcContentType(String) - Static method in class io.grpc.internal.GrpcUtil
-
Indicates whether or not the given value is a valid gRPC content-type.
- isIdempotent() - Method in class io.grpc.MethodDescriptor
-
Returns whether this method is idempotent.
- isOk() - Method in class io.grpc.Status
-
Is this status OK, i.e., not an error.
- isOutboundClosed() - Method in class io.grpc.internal.AbstractClientStream.TransportState
-
- isReady() - Method in class io.grpc.ClientCall
-
If true
, indicates that the call is capable of sending additional messages
without requiring excessive buffering internally.
- 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.
- isReady() - Method in class io.grpc.ServerCall
-
If true
, indicates that the call is capable of sending additional messages
without requiring excessive buffering internally.
- isSafe() - Method in class io.grpc.MethodDescriptor
-
Returns whether this method is safe.
- isSampledToLocalTracing() - Method in class io.grpc.MethodDescriptor
-
Returns whether RPCs for this method may be sampled into the local tracing store.
- isShutdown() - Method in class io.grpc.internal.ServerImpl
-
- isShutdown() - Method in class io.grpc.ManagedChannel
-
Returns whether the channel is shutdown.
- isShutdown() - Method in class io.grpc.Server
-
Returns whether the server is shutdown.
- isTerminated() - Method in class io.grpc.internal.ServerImpl
-
- isTerminated() - Method in class io.grpc.ManagedChannel
-
Returns whether the channel is terminated.
- isTerminated() - Method in class io.grpc.Server
-
Returns whether the server is terminated.
- isWaitForReady() - Method in class io.grpc.CallOptions
-
- ManagedChannel - Class in io.grpc
-
A
Channel
that provides lifecycle management.
- ManagedChannel() - Constructor for class io.grpc.ManagedChannel
-
- ManagedChannelBuilder<T extends ManagedChannelBuilder<T>> - Class in io.grpc
-
- ManagedChannelBuilder() - Constructor for class io.grpc.ManagedChannelBuilder
-
- ManagedChannelProvider - Class in io.grpc
-
Provider of managed channels for transport agnostic consumption.
- ManagedChannelProvider() - Constructor for class io.grpc.ManagedChannelProvider
-
- ManagedChannelProvider.ProviderNotFoundException - Exception in io.grpc
-
- ManagedClientTransport - Interface in io.grpc.internal
-
- ManagedClientTransport.Listener - Interface in io.grpc.internal
-
Receives notifications for the transport life-cycle events.
- maxHedgedAttempts(int) - Method in class io.grpc.ForwardingChannelBuilder
-
- maxHedgedAttempts(int) - Method in class io.grpc.internal.AbstractManagedChannelImplBuilder
-
- maxHedgedAttempts(int) - Method in class io.grpc.ManagedChannelBuilder
-
Sets max number of hedged attempts.
- maxInboundMessageSize(int) - Method in class io.grpc.ForwardingChannelBuilder
-
- 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
-
- maxInboundMessageSize(int) - Method in class io.grpc.ManagedChannelBuilder
-
Sets the maximum message size allowed to be received on the channel.
- maxInboundMessageSize(int) - Method in class io.grpc.ServerBuilder
-
Sets the maximum message size allowed to be received on the server.
- maxRetryAttempts(int) - Method in class io.grpc.ForwardingChannelBuilder
-
- maxRetryAttempts(int) - Method in class io.grpc.internal.AbstractManagedChannelImplBuilder
-
- maxRetryAttempts(int) - Method in class io.grpc.ManagedChannelBuilder
-
Sets max number of retry attempts.
- maxTraceEvents(int) - Method in class io.grpc.ForwardingChannelBuilder
-
- maxTraceEvents(int) - Method in class io.grpc.internal.AbstractManagedChannelImplBuilder
-
- maxTraceEvents(int) - Method in class io.grpc.ManagedChannelBuilder
-
Sets the maximum number of channel trace events to keep in the tracer for each channel or
subchannel.
- merge(Metadata) - Method in class io.grpc.Metadata
-
Perform a simple merge of two sets of metadata.
- merge(Metadata, Set<Metadata.Key<?>>) - Method in class io.grpc.Metadata
-
Merge values from the given set of keys into this set of metadata.
- 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
-
- 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
-
- MESSAGE_KEY - Static variable in class io.grpc.InternalStatus
-
Key to bind status message to trailing metadata.
- 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.
- messagesReceived - Variable in class io.grpc.InternalChannelz.TransportStats
-
- messagesSent - Variable in class io.grpc.InternalChannelz.TransportStats
-
- Metadata - Class in io.grpc
-
Provides access to read and write metadata values to be exchanged during a call.
- Metadata() - Constructor for class io.grpc.Metadata
-
Constructor called by the application layer when it wants to send metadata.
- Metadata.AsciiMarshaller<T> - Interface in io.grpc
-
Marshaller for metadata values that are serialized into ASCII strings.
- Metadata.BinaryMarshaller<T> - Interface in io.grpc
-
Marshaller for metadata values that are serialized into raw binary.
- Metadata.Key<T> - Class in io.grpc
-
Key for metadata entries.
- MetadataApplier() - Constructor for class io.grpc.CallCredentials2.MetadataApplier
-
- MethodDescriptor<ReqT,RespT> - Class in io.grpc
-
Description of a remote method used by
Channel
to initiate a call.
- MethodDescriptor.Builder<ReqT,RespT> - Class in io.grpc
-
- MethodDescriptor.Marshaller<T> - Interface in io.grpc
-
A typed abstraction over message serialization and deserialization, a.k.a.
- MethodDescriptor.MethodType - Enum in io.grpc
-
The call type of a method.
- MethodDescriptor.PrototypeMarshaller<T> - Interface in io.grpc
-
A marshaller that uses a fixed instance of the type it produces.
- MethodDescriptor.ReflectableMarshaller<T> - Interface in io.grpc
-
A marshaller that supports retrieving it's type parameter T
at runtime.
- MoreThrowables - Class in io.grpc.internal
-
Utility functions when interacting with
Throwable
s.
- MutableHandlerRegistry - Class in io.grpc.util
-
- MutableHandlerRegistry() - Constructor for class io.grpc.util.MutableHandlerRegistry
-
- ObjectPool<T> - Interface in io.grpc.internal
-
An object pool.
- of(String) - Static method in class io.grpc.Attributes.Key
-
- of(String, T) - Static method in class io.grpc.CallOptions.Key
-
- of(String, Metadata.BinaryMarshaller<T>) - Static method in class io.grpc.Metadata.Key
-
Creates a key for a binary header.
- of(String, Metadata.AsciiMarshaller<T>) - Static method in class io.grpc.Metadata.Key
-
Creates a key for an ASCII header.
- OK - Static variable in class io.grpc.Status
-
The operation completed successfully.
- onAddresses(List<EquivalentAddressGroup>, Attributes) - Method in interface io.grpc.NameResolver.Listener
-
Handles updates on resolved addresses and attributes.
- onCancel() - Method in class io.grpc.ServerCall.Listener
-
The call was cancelled and the server is encouraged to abort processing to save resources,
since the client will not process any further messages.
- onClose(Status, Metadata) - Method in class io.grpc.ClientCall.Listener
-
The ClientCall has been closed.
- onComplete() - Method in class io.grpc.ServerCall.Listener
-
- onDataReceived() - Method in class io.grpc.internal.KeepAliveManager
-
Transport has received some data so that we can delay sending keepalives.
- onError(Status) - Method in interface io.grpc.NameResolver.Listener
-
Handles an error from the resolver.
- onFailure(Throwable) - Method in interface io.grpc.internal.ClientTransport.PingCallback
-
Invoked when a ping fails.
- onHalfClose() - Method in class io.grpc.ServerCall.Listener
-
The client completed all message sending.
- onHeaders(Metadata) - Method in class io.grpc.ClientCall.Listener
-
The response headers have been received.
- onMessage(T) - Method in class io.grpc.ClientCall.Listener
-
A response message has been received.
- onMessage(RespT) - Method in class io.grpc.ForwardingClientCallListener
-
- onMessage(ReqT) - Method in class io.grpc.ForwardingServerCallListener
-
- onMessage(ReqT) - Method in class io.grpc.ServerCall.Listener
-
A request message has been received.
- 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 class io.grpc.ClientCall.Listener
-
This indicates that the ClientCall is now capable of sending additional messages (via
ClientCall.sendMessage(ReqT)
) without requiring excessive buffering internally.
- 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.
- onReady() - Method in class io.grpc.ServerCall.Listener
-
This indicates that the call is now capable of sending additional messages (via
ServerCall.sendMessage(RespT)
) 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
-
- options - Variable in class io.grpc.InternalChannelz.TcpInfo
-
- originalName() - Method in class io.grpc.Metadata.Key
-
- other - Variable in class io.grpc.InternalChannelz.Security
-
- others - Variable in class io.grpc.InternalChannelz.SocketOptions
-
- OtherSecurity(String, Object) - Constructor for class io.grpc.InternalChannelz.OtherSecurity
-
Creates an instance.
- OUT_OF_RANGE - Static variable in class io.grpc.Status
-
Operation was attempted past the valid range.
- outboundHeaders() - Method in class io.grpc.ClientStreamTracer
-
Headers has been sent to the socket.
- outboundMessage(int) - Method in class io.grpc.internal.StatsTraceContext
-
- outboundMessage(int) - Method in class io.grpc.StreamTracer
-
An outbound message has been passed to the stream.
- outboundMessageSent(int, long, long) - Method in class io.grpc.internal.StatsTraceContext
-
- outboundMessageSent(int, long, long) - Method in class io.grpc.StreamTracer
-
An outbound message has been serialized and sent to the transport.
- outboundUncompressedSize(long) - Method in class io.grpc.internal.StatsTraceContext
-
- outboundUncompressedSize(long) - Method in class io.grpc.StreamTracer
-
The uncompressed size of some outbound data is revealed.
- outboundWireSize(long) - Method in class io.grpc.internal.StatsTraceContext
-
- outboundWireSize(long) - Method in class io.grpc.StreamTracer
-
The wire size of some outbound data is revealed.
- overrideAuthority(String) - Method in class io.grpc.ForwardingChannelBuilder
-
- overrideAuthority(String) - Method in class io.grpc.internal.AbstractManagedChannelImplBuilder
-
- overrideAuthority(String) - Method in class io.grpc.ManagedChannelBuilder
-
Overrides the authority used with TLS and HTTP virtual hosting.
- 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.
- PARAMS_DEFAULT_PORT - Static variable in class io.grpc.NameResolver.Factory
-
The port number used in case the target or the underlying naming system doesn't provide a
port number.
- PARAMS_DEFAULT_PORT - Static variable in class io.grpc.NameResolverProvider
-
The port number used in case the target or the underlying naming system doesn't provide a
port number.
- parse(String) - Static method in class io.grpc.internal.JsonParser
-
Parses a json string, returning either a Map<String, Object>
, List<Object>
,
String
, Double
, Boolean
, or null
.
- parse(InputStream) - Method in interface io.grpc.MethodDescriptor.Marshaller
-
Given an
InputStream
parse it into an instance of the declared type so that it can be
passed to application code.
- parseAsciiString(String) - Method in interface io.grpc.Metadata.AsciiMarshaller
-
Parse a serialized metadata value from an ASCII string.
- parseBytes(byte[]) - Method in interface io.grpc.Metadata.BinaryMarshaller
-
Parse a serialized metadata value from bytes.
- parseRequest(InputStream) - Method in class io.grpc.MethodDescriptor
-
Parse an incoming request message.
- parseResponse(InputStream) - Method in class io.grpc.MethodDescriptor
-
- password - Variable in class io.grpc.internal.ProxyParameters
-
- payload() - Method in class io.grpc.internal.Http2Ping
-
Returns the expected ping payload for this outstanding operation.
- PERMISSION_DENIED - Static variable in class io.grpc.Status
-
The caller does not have permission to execute the specified operation.
- perRpcBufferLimit(long) - Method in class io.grpc.ForwardingChannelBuilder
-
- perRpcBufferLimit(long) - Method in class io.grpc.internal.AbstractManagedChannelImplBuilder
-
- perRpcBufferLimit(long) - Method in class io.grpc.ManagedChannelBuilder
-
Sets the per RPC buffer limit in bytes used for retry.
- PickFirstBalancerFactory - Class in io.grpc
-
- pickSubchannel(LoadBalancer.PickSubchannelArgs) - Method in class io.grpc.LoadBalancer.SubchannelPicker
-
Make a balancing decision for a new RPC.
- PickSubchannelArgs() - Constructor for class io.grpc.LoadBalancer.PickSubchannelArgs
-
- 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.
- pmtu - Variable in class io.grpc.InternalChannelz.TcpInfo
-
- priority() - Method in class io.grpc.internal.DnsNameResolverProvider
-
- priority() - Method in class io.grpc.ManagedChannelProvider
-
A priority, from 0 to 10 that this provider should be used, taking the current environment into
consideration.
- priority() - Method in class io.grpc.NameResolverProvider
-
A priority, from 0 to 10 that this provider should be used, taking the current environment into
consideration.
- priority() - Method in class io.grpc.ServerProvider
-
A priority, from 0 to 10 that this provider should be used, taking the current environment into
consideration.
- probes - Variable in class io.grpc.InternalChannelz.TcpInfo
-
- Provider() - Constructor for class io.grpc.internal.ExponentialBackoffPolicy.Provider
-
- provider() - Static method in class io.grpc.ManagedChannelProvider
-
Returns the ClassLoader-wide default channel.
- provider() - Static method in class io.grpc.ServerProvider
-
Returns the ClassLoader-wide default server.
- ProviderNotFoundException(String) - Constructor for exception io.grpc.ManagedChannelProvider.ProviderNotFoundException
-
- providers() - Static method in class io.grpc.NameResolverProvider
-
Returns non-null
ClassLoader-wide providers, in preference order.
- proxyAddress - Variable in class io.grpc.internal.ProxyParameters
-
- ProxyDetector - Interface in io.grpc.internal
-
A utility class to detect which proxy, if any, should be used for a given
SocketAddress
.
- proxyFor(SocketAddress) - Method in interface io.grpc.internal.ProxyDetector
-
Given a target address, returns which proxy address should be used.
- ProxyParameters - Class in io.grpc.internal
-
Used to express the result of a proxy lookup.
- ProxyParameters(InetSocketAddress, String, String) - Constructor for class io.grpc.internal.ProxyParameters
-
Creates an instance.
- put(Metadata.Key<T>, T) - Method in class io.grpc.Metadata
-
Adds the key, value
pair.
- rcvMss - Variable in class io.grpc.InternalChannelz.TcpInfo
-
- rcvSsthresh - Variable in class io.grpc.InternalChannelz.TcpInfo
-
- rcvWscale - Variable in class io.grpc.InternalChannelz.TcpInfo
-
- 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
-
- 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
-
- readAsString(ReadableBuffer, Charset) - Static method in class io.grpc.internal.ReadableBuffers
-
- readAsStringUtf8(ReadableBuffer) - Static method in class io.grpc.internal.ReadableBuffers
-
- 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
.
- refresh() - Method in class io.grpc.NameResolver
-
Re-resolve the name.
- register(Compressor) - Method in class io.grpc.CompressorRegistry
-
Registers a compressor for both decompression and message encoding negotiation.
- 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.
- remote - Variable in class io.grpc.InternalChannelz.SocketStats
-
- remoteBytes - Variable in class io.grpc.internal.TransportTracer.FlowControlWindows
-
- remoteCert - Variable in class io.grpc.InternalChannelz.Tls
-
- remoteFlowControlWindow - Variable in class io.grpc.InternalChannelz.TransportStats
-
- remove(Metadata.Key<T>, T) - Method in class io.grpc.Metadata
-
Removes the first occurrence of value
for key
.
- removeAll(Metadata.Key<T>) - Method in class io.grpc.Metadata
-
Remove all values for the given key.
- removeClientSocket(InternalInstrumented<InternalChannelz.SocketStats>) - Method in class io.grpc.InternalChannelz
-
- removeListenSocket(InternalInstrumented<InternalChannelz.SocketStats>) - Method in class io.grpc.InternalChannelz
-
- removeRootChannel(InternalInstrumented<InternalChannelz.ChannelStats>) - Method in class io.grpc.InternalChannelz
-
- removeServer(InternalInstrumented<InternalChannelz.ServerStats>) - Method in class io.grpc.InternalChannelz
-
Removes a server.
- removeServerSocket(InternalInstrumented<InternalChannelz.ServerStats>, InternalInstrumented<InternalChannelz.SocketStats>) - Method in class io.grpc.InternalChannelz
-
Removes a server socket.
- removeService(ServerServiceDefinition) - Method in class io.grpc.util.MutableHandlerRegistry
-
Removes a registered service
- removeSubchannel(InternalInstrumented<InternalChannelz.ChannelStats>) - Method in class io.grpc.InternalChannelz
-
- reordering - Variable in class io.grpc.InternalChannelz.TcpInfo
-
- 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.ClientCall
-
- 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
-
- request(int) - Method in class io.grpc.ServerCall
-
- requestConnection() - Method in class io.grpc.LoadBalancer.Subchannel
-
Asks the Subchannel to create a connection (aka transport), if there isn't an active one.
- requestConnection() - Method in class io.grpc.LoadBalancer.SubchannelPicker
-
Tries to establish connections now so that the upcoming RPC may then just pick a ready
connection without having to connect first.
- RequestInfo() - Constructor for class io.grpc.CallCredentials.RequestInfo
-
- requestMessagesFromDeframer(int) - Method in class io.grpc.internal.AbstractStream.TransportState
-
Called to request the given number of messages from the deframer.
- resetConnectBackoff() - Method in class io.grpc.ManagedChannel
-
For subchannels that are in TRANSIENT_FAILURE state, short-circuit the backoff timer and make
them reconnect immediately.
- RESOURCE_EXHAUSTED - Static variable in class io.grpc.Status
-
Some resource has been exhausted, perhaps a per-user quota, or perhaps the entire file system
is out of space.
- retrans - Variable in class io.grpc.InternalChannelz.TcpInfo
-
- retransmits - Variable in class io.grpc.InternalChannelz.TcpInfo
-
- retryBufferSize(long) - Method in class io.grpc.ForwardingChannelBuilder
-
- retryBufferSize(long) - Method in class io.grpc.internal.AbstractManagedChannelImplBuilder
-
- retryBufferSize(long) - Method in class io.grpc.ManagedChannelBuilder
-
Sets the retry buffer size in bytes.
- 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
-
- RootChannelList(List<InternalInstrumented<InternalChannelz.ChannelStats>>, boolean) - Constructor for class io.grpc.InternalChannelz.RootChannelList
-
Creates an instance.
- RoundRobinLoadBalancerFactory - Class in io.grpc.util
-
- rto - Variable in class io.grpc.InternalChannelz.TcpInfo
-
- rtt - Variable in class io.grpc.InternalChannelz.TcpInfo
-
- rttvar - Variable in class io.grpc.InternalChannelz.TcpInfo
-
- run() - Method in class io.grpc.internal.LogExceptionRunnable
-
- run() - Method in class io.grpc.internal.SerializingExecutor
-
- runSerialized(Runnable) - Method in class io.grpc.LoadBalancer.Helper
-
Schedule a task to be run in the Channel Executor, which serializes the task with the
callback methods on the
LoadBalancer
interface.
- runSerialized(Runnable) - Method in class io.grpc.util.ForwardingLoadBalancerHelper
-
- sacked - Variable in class io.grpc.InternalChannelz.TcpInfo
-
- 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.
- Security(InternalChannelz.Tls) - Constructor for class io.grpc.InternalChannelz.Security
-
- Security(InternalChannelz.OtherSecurity) - Constructor for class io.grpc.InternalChannelz.Security
-
- security - Variable in class io.grpc.InternalChannelz.SocketStats
-
- SecurityLevel - Enum in io.grpc
-
The level of security guarantee in communications.
- sendHeaders(Metadata) - Method in class io.grpc.ServerCall
-
Send response header metadata prior to sending a response message.
- sendMessage(ReqT) - Method in class io.grpc.ClientCall
-
Send a request message to the server.
- sendMessage(ReqT) - Method in class io.grpc.ForwardingClientCall
-
- sendMessage(RespT) - Method in class io.grpc.ForwardingServerCall
-
- sendMessage(RespT) - Method in class io.grpc.ServerCall
-
Send a response message.
- serialize(Metadata) - Static method in class io.grpc.InternalMetadata
-
- 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 - Class in io.grpc
-
Server for listening for and dispatching incoming calls.
- Server() - Constructor for class io.grpc.Server
-
- SERVER_KEEPALIVE_TIME_NANOS_DISABLED - Static variable in class io.grpc.internal.GrpcUtil
-
The magic keepalive time value that disables keepalive.
- ServerBuilder<T extends ServerBuilder<T>> - Class in io.grpc
-
A builder for
Server
instances.
- ServerBuilder() - Constructor for class io.grpc.ServerBuilder
-
- ServerCall<ReqT,RespT> - Class in io.grpc
-
Encapsulates a single call received from a remote client.
- ServerCall() - Constructor for class io.grpc.ServerCall
-
- ServerCall.Listener<ReqT> - Class in io.grpc
-
Callbacks for consuming incoming RPC messages.
- ServerCallHandler<RequestT,ResponseT> - Interface in io.grpc
-
Interface to initiate processing of incoming remote calls.
- ServerCallInfo() - Constructor for class io.grpc.ServerStreamTracer.ServerCallInfo
-
- serverCallStarted(ServerStreamTracer.ServerCallInfo<?, ?>) - Method in class io.grpc.internal.StatsTraceContext
-
- serverCallStarted(ServerStreamTracer.ServerCallInfo<?, ?>) - Method in class io.grpc.ServerStreamTracer
-
- serverCallStarted(ServerCall<?, ?>) - Method in class io.grpc.ServerStreamTracer
-
- serverFilterContext(Context) - Method in class io.grpc.internal.StatsTraceContext
-
- ServerImpl - Class in io.grpc.internal
-
Default implementation of
Server
, for creation by transports.
- ServerInterceptor - Interface in io.grpc
-
Interface for intercepting incoming calls before that are dispatched by
ServerCallHandler
.
- ServerInterceptors - Class in io.grpc
-
- ServerList(List<InternalInstrumented<InternalChannelz.ServerStats>>, boolean) - Constructor for class io.grpc.InternalChannelz.ServerList
-
Creates an instance.
- ServerListener - Interface in io.grpc.internal
-
A listener to a server for transport creation events.
- ServerMethodDefinition<ReqT,RespT> - Class in io.grpc
-
Definition of a method exposed by a
Server
.
- ServerProvider - Class in io.grpc
-
Provider of servers for transport agnostic consumption.
- ServerProvider() - Constructor for class io.grpc.ServerProvider
-
- servers - Variable in class io.grpc.InternalChannelz.ServerList
-
- serverSendsOneMessage() - Method in enum io.grpc.MethodDescriptor.MethodType
-
- ServerServiceDefinition - Class in io.grpc
-
Definition of a service to be exposed via a Server.
- ServerServiceDefinition.Builder - Class in io.grpc
-
Builder for constructing Service instances.
- serverShutdown() - Method in interface io.grpc.internal.ServerListener
-
The server is shutting down.
- ServerSocketsList(List<InternalWithLogId>, boolean) - Constructor for class io.grpc.InternalChannelz.ServerSocketsList
-
Creates an instance.
- ServerStats(long, long, long, long, List<InternalInstrumented<InternalChannelz.SocketStats>>) - Constructor for class io.grpc.InternalChannelz.ServerStats
-
Creates an instance.
- 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.
- ServerStreamTracer - Class in io.grpc
-
Listens to events on a stream to collect metrics.
- ServerStreamTracer() - Constructor for class io.grpc.ServerStreamTracer
-
- ServerStreamTracer.Factory - Class in io.grpc
-
- ServerStreamTracer.ServerCallInfo<ReqT,RespT> - Class in io.grpc
-
A data class with info about the started
ServerCall
.
- ServerTransport - Interface in io.grpc.internal
-
An inbound connection.
- ServerTransportFilter - Class in io.grpc
-
Listens on server transport life-cycle events, with the capability to read and/or change
transport attributes.
- ServerTransportFilter() - Constructor for class io.grpc.ServerTransportFilter
-
- 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.
- ServiceDescriptor - Class in io.grpc
-
Descriptor for a service.
- ServiceDescriptor(String, MethodDescriptor<?, ?>...) - Constructor for class io.grpc.ServiceDescriptor
-
Constructs a new Service Descriptor.
- ServiceDescriptor(String, Collection<MethodDescriptor<?, ?>>) - Constructor for class io.grpc.ServiceDescriptor
-
Constructs a new Service Descriptor.
- ServiceDescriptor.Builder - Class in io.grpc
-
- set(Attributes.Key<T>, T) - Method in class io.grpc.Attributes.Builder
-
- setAdvmss(int) - Method in class io.grpc.InternalChannelz.TcpInfo.Builder
-
- setAll(Attributes) - Method in class io.grpc.Attributes.Builder
-
- setAto(int) - Method in class io.grpc.InternalChannelz.TcpInfo.Builder
-
- 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
-
- setBackoff(int) - Method in class io.grpc.InternalChannelz.TcpInfo.Builder
-
- setBinaryLog(BinaryLog) - Method in class io.grpc.ForwardingChannelBuilder
-
- setBinaryLog(BinaryLog) - Method in class io.grpc.internal.AbstractManagedChannelImplBuilder
-
- setBinaryLog(BinaryLog) - Method in class io.grpc.internal.AbstractServerImplBuilder
-
- setBinaryLog(BinaryLog) - Method in class io.grpc.ManagedChannelBuilder
-
Sets the BinaryLog object that this channel should log to.
- setBinaryLog(BinaryLog) - Method in class io.grpc.ServerBuilder
-
Sets the BinaryLog object that this server should log to.
- setCallsFailed(long) - Method in class io.grpc.InternalChannelz.ChannelStats.Builder
-
- setCallsFailed(long) - Method in class io.grpc.InternalChannelz.ServerStats.Builder
-
- setCallsStarted(long) - Method in class io.grpc.InternalChannelz.ChannelStats.Builder
-
- setCallsStarted(long) - Method in class io.grpc.InternalChannelz.ServerStats.Builder
-
- setCallsSucceeded(long) - Method in class io.grpc.InternalChannelz.ChannelStats.Builder
-
- setCallsSucceeded(long) - Method in class io.grpc.InternalChannelz.ServerStats.Builder
-
- setCaState(int) - Method in class io.grpc.InternalChannelz.TcpInfo.Builder
-
- setChannelRef(InternalWithLogId) - Method in class io.grpc.InternalChannelz.ChannelTrace.Event.Builder
-
- setChannelTrace(InternalChannelz.ChannelTrace) - Method in class io.grpc.InternalChannelz.ChannelStats.Builder
-
- setCompression(String) - Method in class io.grpc.ServerCall
-
Sets the compression algorithm for this call.
- 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.
- setCreationTimeNanos(long) - Method in class io.grpc.InternalChannelz.ChannelTrace.Builder
-
- 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
-
- setDescription(String) - Method in class io.grpc.InternalChannelz.ChannelTrace.Event.Builder
-
- setEagAttributes(Attributes) - Method in class io.grpc.internal.ClientTransportFactory.ClientTransportOptions
-
Sets the non-null EquivalentAddressGroup's attributes.
- setEvents(List<InternalChannelz.ChannelTrace.Event>) - Method in class io.grpc.InternalChannelz.ChannelTrace.Builder
-
- setFackets(int) - Method in class io.grpc.InternalChannelz.TcpInfo.Builder
-
- setFlowControlWindowReader(TransportTracer.FlowControlReader) - Method in class io.grpc.internal.TransportTracer
-
- setFullMethodName(String) - Method in class io.grpc.MethodDescriptor.Builder
-
Sets the fully qualified (service and method) method name.
- 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
-
- setIdempotent(boolean) - Method in class io.grpc.MethodDescriptor.Builder
-
Sets whether the method is idempotent.
- setLastAckRecv(int) - Method in class io.grpc.InternalChannelz.TcpInfo.Builder
-
- setLastAckSent(int) - Method in class io.grpc.InternalChannelz.TcpInfo.Builder
-
- setLastCallStartedNanos(long) - Method in class io.grpc.InternalChannelz.ChannelStats.Builder
-
- setLastCallStartedNanos(long) - Method in class io.grpc.InternalChannelz.ServerStats.Builder
-
- setLastDataRecv(int) - Method in class io.grpc.InternalChannelz.TcpInfo.Builder
-
- setLastDataSent(int) - Method in class io.grpc.InternalChannelz.TcpInfo.Builder
-
- 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.
- setListenSockets(List<InternalInstrumented<InternalChannelz.SocketStats>>) - Method in class io.grpc.InternalChannelz.ServerStats.Builder
-
Sets the listen sockets.
- setLost(int) - Method in class io.grpc.InternalChannelz.TcpInfo.Builder
-
- 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.ClientCall
-
Enables per-message compression, if an encoding type has been negotiated.
- 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.
- setMessageCompression(boolean) - Method in class io.grpc.ServerCall
-
Enables per-message compression, if an encoding type has been negotiated.
- setName(String) - Method in class io.grpc.ServiceDescriptor.Builder
-
Sets the name.
- setNumEventsLogged(long) - Method in class io.grpc.InternalChannelz.ChannelTrace.Builder
-
- setOptions(int) - Method in class io.grpc.InternalChannelz.TcpInfo.Builder
-
- setPmtu(int) - Method in class io.grpc.InternalChannelz.TcpInfo.Builder
-
- setProbes(int) - Method in class io.grpc.InternalChannelz.TcpInfo.Builder
-
- setProxyParameters(ProxyParameters) - Method in class io.grpc.internal.ClientTransportFactory.ClientTransportOptions
-
- setRawMethodName(MethodDescriptor<?, ?>, Object) - Method in class io.grpc.InternalMethodDescriptor
-
- setRcvMss(int) - Method in class io.grpc.InternalChannelz.TcpInfo.Builder
-
- setRcvSsthresh(int) - Method in class io.grpc.InternalChannelz.TcpInfo.Builder
-
- setRcvWscale(int) - Method in class io.grpc.InternalChannelz.TcpInfo.Builder
-
- setReordering(int) - Method in class io.grpc.InternalChannelz.TcpInfo.Builder
-
- setRequestMarshaller(MethodDescriptor.Marshaller<ReqT>) - Method in class io.grpc.MethodDescriptor.Builder
-
Sets the request marshaller.
- setResponseMarshaller(MethodDescriptor.Marshaller<RespT>) - Method in class io.grpc.MethodDescriptor.Builder
-
Sets the response marshaller.
- setRetrans(int) - Method in class io.grpc.InternalChannelz.TcpInfo.Builder
-
- setRetransmits(int) - Method in class io.grpc.InternalChannelz.TcpInfo.Builder
-
- setRto(int) - Method in class io.grpc.InternalChannelz.TcpInfo.Builder
-
- setRtt(int) - Method in class io.grpc.InternalChannelz.TcpInfo.Builder
-
- setRttvar(int) - Method in class io.grpc.InternalChannelz.TcpInfo.Builder
-
- setSacked(int) - Method in class io.grpc.InternalChannelz.TcpInfo.Builder
-
- setSafe(boolean) - Method in class io.grpc.MethodDescriptor.Builder
-
Sets whether this method is safe.
- setSampledToLocalTracing(boolean) - Method in class io.grpc.MethodDescriptor.Builder
-
Sets whether RPCs for this method may be sampled into the local tracing store.
- setSchemaDescriptor(Object) - Method in class io.grpc.MethodDescriptor.Builder
-
Sets the schema descriptor for this builder.
- setSchemaDescriptor(Object) - Method in class io.grpc.ServiceDescriptor.Builder
-
Sets the schema descriptor for this builder.
- setSeverity(InternalChannelz.ChannelTrace.Event.Severity) - Method in class io.grpc.InternalChannelz.ChannelTrace.Event.Builder
-
- setSndCwnd(int) - Method in class io.grpc.InternalChannelz.TcpInfo.Builder
-
- setSndMss(int) - Method in class io.grpc.InternalChannelz.TcpInfo.Builder
-
- setSndSsthresh(int) - Method in class io.grpc.InternalChannelz.TcpInfo.Builder
-
- setSndWscale(int) - Method in class io.grpc.InternalChannelz.TcpInfo.Builder
-
- setSocketOptionLingerSeconds(Integer) - Method in class io.grpc.InternalChannelz.SocketOptions.Builder
-
- setSocketOptionTimeoutMillis(Integer) - Method in class io.grpc.InternalChannelz.SocketOptions.Builder
-
- setSockets(List<InternalWithLogId>) - Method in class io.grpc.InternalChannelz.ChannelStats.Builder
-
Sets the sockets.
- setState(ConnectivityState) - Method in class io.grpc.InternalChannelz.ChannelStats.Builder
-
- setState(int) - Method in class io.grpc.InternalChannelz.TcpInfo.Builder
-
- 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.
- 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.
- setSubchannelRef(InternalWithLogId) - Method in class io.grpc.InternalChannelz.ChannelTrace.Event.Builder
-
- setSubchannels(List<InternalWithLogId>) - Method in class io.grpc.InternalChannelz.ChannelStats.Builder
-
Sets the subchannels.
- setTarget(String) - Method in class io.grpc.InternalChannelz.ChannelStats.Builder
-
- setTcpInfo(InternalChannelz.TcpInfo) - Method in class io.grpc.InternalChannelz.SocketOptions.Builder
-
- setTimestampNanos(long) - Method in class io.grpc.InternalChannelz.ChannelTrace.Event.Builder
-
- 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.
- setType(MethodDescriptor.MethodType) - Method in class io.grpc.MethodDescriptor.Builder
-
Sets the method type.
- setUnacked(int) - Method in class io.grpc.InternalChannelz.TcpInfo.Builder
-
- setUserAgent(String) - Method in class io.grpc.internal.ClientTransportFactory.ClientTransportOptions
-
- severity - Variable in class io.grpc.InternalChannelz.ChannelTrace.Event
-
- 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
-
- 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.LoadBalancer
-
The channel asks the load-balancer to shutdown.
- shutdown() - Method in class io.grpc.LoadBalancer.Subchannel
-
Shuts down the Subchannel.
- shutdown() - Method in class io.grpc.ManagedChannel
-
Initiates an orderly shutdown in which preexisting calls continue but new calls are immediately
cancelled.
- shutdown() - Method in class io.grpc.NameResolver
-
Stops the resolution.
- shutdown() - Method in class io.grpc.Server
-
Initiates an orderly shutdown in which preexisting calls continue but new calls are rejected.
- 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.
- shutdownNow() - Method in class io.grpc.ManagedChannel
-
Initiates a forceful shutdown in which preexisting and new calls are cancelled.
- shutdownNow() - Method in class io.grpc.Server
-
Initiates a forceful shutdown in which preexisting and new calls are rejected.
- SimpleForwardingClientCall(ClientCall<ReqT, RespT>) - Constructor for class io.grpc.ForwardingClientCall.SimpleForwardingClientCall
-
- SimpleForwardingClientCallListener(ClientCall.Listener<RespT>) - Constructor for class io.grpc.ForwardingClientCallListener.SimpleForwardingClientCallListener
-
- SimpleForwardingServerCall(ServerCall<ReqT, RespT>) - Constructor for class io.grpc.ForwardingServerCall.SimpleForwardingServerCall
-
- SimpleForwardingServerCallListener(ServerCall.Listener<ReqT>) - Constructor for class io.grpc.ForwardingServerCallListener.SimpleForwardingServerCallListener
-
- 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.
- sndCwnd - Variable in class io.grpc.InternalChannelz.TcpInfo
-
- sndMss - Variable in class io.grpc.InternalChannelz.TcpInfo
-
- sndSsthresh - Variable in class io.grpc.InternalChannelz.TcpInfo
-
- sndWscale - Variable in class io.grpc.InternalChannelz.TcpInfo
-
- SocketOptions(Integer, Integer, InternalChannelz.TcpInfo, Map<String, String>) - Constructor for class io.grpc.InternalChannelz.SocketOptions
-
Creates an instance.
- socketOptions - Variable in class io.grpc.InternalChannelz.SocketStats
-
- sockets - Variable in class io.grpc.InternalChannelz.ChannelStats
-
- sockets - Variable in class io.grpc.InternalChannelz.ServerSocketsList
-
- SocketStats(InternalChannelz.TransportStats, SocketAddress, SocketAddress, InternalChannelz.SocketOptions, InternalChannelz.Security) - Constructor for class io.grpc.InternalChannelz.SocketStats
-
Creates an instance.
- soTimeoutMillis - Variable in class io.grpc.InternalChannelz.SocketOptions
-
- start(ClientCall.Listener<RespT>, Metadata) - Method in class io.grpc.ClientCall
-
Start a call, using responseListener
for processing response messages.
- start(ClientCall.Listener<RespT>, Metadata) - Method in class io.grpc.ClientInterceptors.CheckedForwardingClientCall
-
- start(ClientCall.Listener<RespT>, Metadata) - Method in class io.grpc.ForwardingClientCall
-
- 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(NameResolver.Listener) - Method in class io.grpc.NameResolver
-
Starts the resolution.
- start() - Method in class io.grpc.Server
-
Bind and start the server.
- startCall(ServerCall<RequestT, ResponseT>, Metadata) - Method in interface io.grpc.ServerCallHandler
-
Produce a non-null
listener for the incoming call.
- state - Variable in class io.grpc.InternalChannelz.ChannelStats
-
- state - Variable in class io.grpc.InternalChannelz.TcpInfo
-
- 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.
- Status - Class in io.grpc
-
Defines the status of an operation by providing a standard
Status.Code
in conjunction with an
optional descriptive message.
- Status.Code - Enum in io.grpc
-
The set of canonical status codes.
- StatusException - Exception in io.grpc
-
Status
in Exception form, for propagating Status information via exceptions.
- StatusException(Status) - Constructor for exception io.grpc.StatusException
-
Constructs an exception with both a status.
- StatusException(Status, Metadata) - Constructor for exception io.grpc.StatusException
-
Constructs an exception with both a status and trailers.
- statusForCode(long) - Static method in enum io.grpc.internal.GrpcUtil.Http2Error
-
Looks up the
Status
from the given HTTP/2 error code.
- statusFromCancelled(Context) - Static method in class io.grpc.Contexts
-
Returns the
Status
of a cancelled context or
null
if the context
is not cancelled.
- StatusRuntimeException - Exception in io.grpc
-
Status
in RuntimeException form, for propagating Status information via exceptions.
- StatusRuntimeException(Status) - Constructor for exception io.grpc.StatusRuntimeException
-
Constructs the exception with both a status.
- StatusRuntimeException(Status, Metadata) - Constructor for exception io.grpc.StatusRuntimeException
-
Constructs the exception with both a status and trailers.
- 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.
- stream(T) - Method in interface io.grpc.MethodDescriptor.Marshaller
-
Given a message, produce an
InputStream
for it so that it can be written to the wire.
- streamClosed(Status) - Method in class io.grpc.internal.StatsTraceContext
-
- streamClosed(Status) - Method in class io.grpc.StreamTracer
-
Stream is closed.
- streamCreated(ServerStream, String, Metadata) - Method in interface io.grpc.internal.ServerTransportListener
-
Called when a new stream was created by the remote client.
- StreamListener - Interface in io.grpc.internal
-
- StreamListener.MessageProducer - Interface in io.grpc.internal
-
A producer for deframed gRPC messages.
- streamRequest(ReqT) - Method in class io.grpc.MethodDescriptor
-
- streamResponse(RespT) - Method in class io.grpc.MethodDescriptor
-
Serialize an outgoing response message.
- streamsFailed - Variable in class io.grpc.InternalChannelz.TransportStats
-
- streamsStarted - Variable in class io.grpc.InternalChannelz.TransportStats
-
- streamsSucceeded - Variable in class io.grpc.InternalChannelz.TransportStats
-
- StreamTracer - Class in io.grpc
-
Listens to events on a stream to collect metrics.
- StreamTracer() - Constructor for class io.grpc.StreamTracer
-
- Subchannel() - Constructor for class io.grpc.LoadBalancer.Subchannel
-
- SubchannelPicker() - Constructor for class io.grpc.LoadBalancer.SubchannelPicker
-
- subchannelRef - Variable in class io.grpc.InternalChannelz.ChannelTrace.Event
-
- subchannels - Variable in class io.grpc.InternalChannelz.ChannelStats
-
- SYSTEM_TIME_PROVIDER - Static variable in interface io.grpc.internal.TimeProvider
-
- target - Variable in class io.grpc.InternalChannelz.ChannelStats
-
- tcpInfo - Variable in class io.grpc.InternalChannelz.SocketOptions
-
- TE_HEADER - Static variable in class io.grpc.internal.GrpcUtil
-
- TE_TRAILERS - Static variable in class io.grpc.internal.GrpcUtil
-
The TE (transport encoding) header for requests over HTTP/2.
- thisT() - Method in class io.grpc.ForwardingChannelBuilder
-
Returns the correctly typed version of the builder.
- thisUsesUnstableApi() - Method in interface io.grpc.CallCredentials
-
Should be a noop but never called; tries to make it clearer to implementors that they may break
in the future.
- throwIfUnchecked(Throwable) - Static method in class io.grpc.internal.MoreThrowables
-
- TIMEOUT - Static variable in class io.grpc.internal.GrpcUtil
-
The Timeout header name.
- TIMEOUT_KEY - Static variable in class io.grpc.internal.GrpcUtil
-
- 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.
- timestampNanos - Variable in class io.grpc.InternalChannelz.ChannelTrace.Event
-
- tls - Variable in class io.grpc.InternalChannelz.Security
-
- Tls(String, Certificate, Certificate) - Constructor for class io.grpc.InternalChannelz.Tls
-
A constructor only for testing.
- Tls(SSLSession) - Constructor for class io.grpc.InternalChannelz.Tls
-
Creates an instance.
- toAsciiString(T) - Method in interface io.grpc.Metadata.AsciiMarshaller
-
Serialize a metadata value to a ASCII string that contains only the characters listed in the
class comment of
Metadata.AsciiMarshaller
.
- toBuilder() - Method in class io.grpc.Attributes
-
Creates a new builder that is pre-populated with the content of this container.
- toBuilder() - Method in class io.grpc.MethodDescriptor
-
Turns this descriptor into a builder.
- toBuilder(MethodDescriptor.Marshaller<NewReqT>, MethodDescriptor.Marshaller<NewRespT>) - Method in class io.grpc.MethodDescriptor
-
Turns this descriptor into a builder, replacing the request and response marshallers.
- toByteArray(InputStream) - Static method in class io.grpc.internal.IoUtils
-
Returns the byte array.
- toBytes(T) - Method in interface io.grpc.Metadata.BinaryMarshaller
-
Serialize a metadata value to bytes.
- 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.
- toStatus() - Method in enum io.grpc.Status.Code
-
Returns a
Status
object corresponding to this status code.
- toString() - Method in class io.grpc.Attributes.Key
-
- toString() - Method in class io.grpc.Attributes
-
- toString() - Method in class io.grpc.CallOptions.Key
-
- toString() - Method in class io.grpc.CallOptions
-
- toString() - Method in class io.grpc.ConnectivityStateInfo
-
- toString() - Method in class io.grpc.EquivalentAddressGroup
-
- toString() - Method in class io.grpc.ForwardingChannelBuilder
-
- toString() - Method in class io.grpc.inprocess.InProcessSocketAddress
-
- toString() - Method in class io.grpc.internal.ForwardingReadableBuffer
-
- toString() - Method in class io.grpc.internal.LogExceptionRunnable
-
- toString() - Method in class io.grpc.internal.ServerImpl
-
- toString() - Method in class io.grpc.InternalChannelz.ChannelTrace.Event
-
- toString() - Method in class io.grpc.InternalLogId
-
- toString() - Method in class io.grpc.LoadBalancer.PickResult
-
- toString() - Method in class io.grpc.LoadBalancer
-
- toString() - Method in class io.grpc.Metadata.Key
-
- toString() - Method in class io.grpc.Metadata
-
- toString() - Method in class io.grpc.MethodDescriptor
-
- toString() - Method in class io.grpc.ServiceDescriptor
-
- toString() - Method in class io.grpc.Status
-
A string representation of the status useful for debugging.
- toString() - Method in class io.grpc.util.ForwardingLoadBalancerHelper
-
- trailersFromThrowable(Throwable) - Static method in class io.grpc.Status
-
Extract an error trailers from the causal chain of a
Throwable
.
- 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.
- TRANSPORT_ATTR_LOCAL_ADDR - Static variable in class io.grpc.Grpc
-
Attribute key for the local address of a transport.
- TRANSPORT_ATTR_REMOTE_ADDR - Static variable in class io.grpc.Grpc
-
Attribute key for the remote address of a transport.
- TRANSPORT_ATTR_SSL_SESSION - Static variable in class io.grpc.Grpc
-
Attribute key for SSL session of a transport.
- 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.
- transportReady(Attributes) - Method in class io.grpc.ServerTransportFilter
-
Called when a transport 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
-
- TransportStats(long, long, long, long, long, long, long, long, long, long, long, long) - Constructor for class io.grpc.InternalChannelz.TransportStats
-
Creates an instance.
- 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.
- transportTerminated(Attributes) - Method in class io.grpc.ServerTransportFilter
-
Called when a transport is terminated.
- 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
-
- transportTracerFactory - Variable in class io.grpc.internal.AbstractServerImplBuilder
-
- transportTrailersReceived(Metadata) - Method in class io.grpc.internal.Http2ClientStreamTransportState
-
Called by subclasses for the terminal trailer metadata on a stream.
- value() - Method in interface io.grpc.internal.LongCounter
-
Returns the value of this counter.
- value() - Method in class io.grpc.internal.ReflectionLongAdderCounter
-
- value() - Method in enum io.grpc.Status.Code
-
The numerical value of the code.
- valueOf(String) - Static method in enum io.grpc.ConnectivityState
-
Returns the enum constant of this type with the specified name.
- 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.
- valueOf(String) - Static method in enum io.grpc.InternalChannelz.ChannelTrace.Event.Severity
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.grpc.InternalKnownTransport
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.grpc.MethodDescriptor.MethodType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.grpc.SecurityLevel
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.grpc.Status.Code
-
Returns the enum constant of this type with the specified name.
- values() - Static method in enum io.grpc.ConnectivityState
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- 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.
- values() - Static method in enum io.grpc.InternalChannelz.ChannelTrace.Event.Severity
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum io.grpc.InternalKnownTransport
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum io.grpc.MethodDescriptor.MethodType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum io.grpc.SecurityLevel
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum io.grpc.Status.Code
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- with(Decompressor, boolean) - Method in class io.grpc.DecompressorRegistry
-
Registers a decompressor for both decompression and message encoding negotiation.
- withAuthority(String) - Method in class io.grpc.CallOptions
-
Override the HTTP/2 authority the channel claims to be connecting to.
- withCallCredentials(CallCredentials) - Method in class io.grpc.CallOptions
-
Returns a new CallOptions
with the given call credentials.
- withCause(Throwable) - Method in class io.grpc.Status
-
Create a derived instance of
Status
with the given cause.
- withCompression(String) - Method in class io.grpc.CallOptions
-
Sets the compression to use for the call.
- withDeadline(Deadline) - Method in class io.grpc.CallOptions
-
Returns a new CallOptions
with the given absolute deadline.
- withDeadlineAfter(long, TimeUnit) - Method in class io.grpc.CallOptions
-
Returns a new CallOptions
with a deadline that is after the given duration
from
now.
- withDescription(String) - Method in class io.grpc.Status
-
Create a derived instance of
Status
with the given description.
- withDrop(Status) - Static method in class io.grpc.LoadBalancer.PickResult
-
A decision to fail an RPC immediately.
- withError(Status) - Static method in class io.grpc.LoadBalancer.PickResult
-
A decision to report a connectivity error to the RPC.
- withExecutor(Executor) - Method in class io.grpc.CallOptions
-
- withMaxInboundMessageSize(int) - Method in class io.grpc.CallOptions
-
Sets the maximum allowed message size acceptable from the remote peer.
- withMaxOutboundMessageSize(int) - Method in class io.grpc.CallOptions
-
Sets the maximum allowed message size acceptable sent to the remote peer.
- withNoResult() - Static method in class io.grpc.LoadBalancer.PickResult
-
No decision could be made.
- withOption(CallOptions.Key<T>, T) - Method in class io.grpc.CallOptions
-
Sets a custom option.
- withoutWaitForReady() - Method in class io.grpc.CallOptions
-
Disables 'wait for ready' feature for the call.
- withServerCallHandler(ServerCallHandler<ReqT, RespT>) - Method in class io.grpc.ServerMethodDefinition
-
Create a new method definition with a different call handler.
- withStreamTracerFactory(ClientStreamTracer.Factory) - Method in class io.grpc.CallOptions
-
Returns a new CallOptions
with a ClientStreamTracerFactory
in addition to
the existing factories.
- withSubchannel(LoadBalancer.Subchannel, ClientStreamTracer.Factory) - Static method in class io.grpc.LoadBalancer.PickResult
-
A decision to proceed the RPC on a Subchannel.
- withSubchannel(LoadBalancer.Subchannel) - Static method in class io.grpc.LoadBalancer.PickResult
-
Equivalent to withSubchannel(subchannel, null)
.
- withWaitForReady() - Method in class io.grpc.CallOptions
-
- 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
-
- wrap(ByteBuffer) - Static method in class io.grpc.internal.ReadableBuffers
-
- wrapChannel(Channel) - Method in class io.grpc.BinaryLog
-
- wrapClientInterceptor(ClientInterceptor, MethodDescriptor.Marshaller<ReqT>, MethodDescriptor.Marshaller<RespT>) - Static method in class io.grpc.InternalClientInterceptors
-
- wrapMethod(ServerMethodDefinition<OrigReqT, OrigRespT>, MethodDescriptor<WrapReqT, WrapRespT>) - Static method in class io.grpc.InternalServerInterceptors
-
- wrapMethodDefinition(ServerMethodDefinition<ReqT, RespT>) - Method in class io.grpc.BinaryLog
-
- 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.