- 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.
- abortStream(Status, boolean) - Method in class io.grpc.internal.AbstractServerStream
-
Aborts the stream with an error status, cleans up resources and notifies the listener if
necessary.
- AbstractChannelBuilder<BuilderT extends AbstractChannelBuilder<BuilderT>> - Class in io.grpc
-
The base class for channel builders.
- AbstractChannelBuilder() - Constructor for class io.grpc.AbstractChannelBuilder
-
- AbstractChannelBuilder.ChannelEssentials - Class in io.grpc
-
The essentials required for creating a channel.
- AbstractClientStream<IdT> - Class in io.grpc.internal
-
- AbstractClientStream(WritableBufferAllocator, ClientStreamListener) - Constructor for class io.grpc.internal.AbstractClientStream
-
Constructor used by subclasses.
- AbstractReadableBuffer - Class in io.grpc.internal
-
- AbstractReadableBuffer() - Constructor for class io.grpc.internal.AbstractReadableBuffer
-
- AbstractServerBuilder<BuilderT extends AbstractServerBuilder<BuilderT>> - Class in io.grpc
-
The base class for server builders.
- AbstractServerBuilder(HandlerRegistry) - Constructor for class io.grpc.AbstractServerBuilder
-
Constructs using a given handler registry.
- AbstractServerBuilder() - Constructor for class io.grpc.AbstractServerBuilder
-
Constructs with a MutableHandlerRegistry created internally.
- AbstractServerBuilder.ServerEssentials - Class in io.grpc
-
The essentials required for creating a server.
- AbstractServerStream<IdT> - Class in io.grpc.internal
-
- AbstractServerStream(WritableBufferAllocator) - Constructor for class io.grpc.internal.AbstractServerStream
-
- AbstractStream<IdT> - Class in io.grpc.internal
-
Abstract base class for
Stream
implementations.
- AbstractStream.Phase - Enum in io.grpc.internal
-
Indicates the phase of the GRPC stream in one direction.
- AbstractStub<S extends AbstractStub<?>> - Class in io.grpc.stub
-
Common base type for stub implementations.
- AbstractStub(Channel) - Constructor for class io.grpc.stub.AbstractStub
-
Constructor for use by subclasses, with the default CallOptions
.
- AbstractStub(Channel, CallOptions) - Constructor for class io.grpc.stub.AbstractStub
-
Constructor for use by subclasses, with the default CallOptions
.
- 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.
- addListener(Context.CancellationListener, Executor) - Method in class io.grpc.Context
-
Add a listener that will be notified when the context becomes cancelled.
- 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.
- addService(ServerServiceDefinition) - Method in class io.grpc.AbstractServerBuilder
-
Adds a service implementation to the handler registry.
- addService(ServerServiceDefinition) - Method in class io.grpc.MutableHandlerRegistry
-
Returns null
, or previous service if service
replaced an existing service.
- addService(ServerServiceDefinition) - Method in class io.grpc.MutableHandlerRegistryImpl
-
- allocate(int) - Method in interface io.grpc.internal.WritableBufferAllocator
-
- ALREADY_EXISTS - Static variable in class io.grpc.Status
-
Some entity that we attempted to create (e.g., file or directory) already exists.
- 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
-
- asRuntimeException() - Method in class io.grpc.Status
-
- asyncBidiStreamingCall(ClientCall<ReqT, RespT>, StreamObserver<RespT>) - Static method in class io.grpc.stub.ClientCalls
-
Executes a bidi-streaming call.
- asyncBidiStreamingCall(ServerCalls.BidiStreamingMethod<ReqT, RespT>) - Static method in class io.grpc.stub.ServerCalls
-
Creates a ServerCallHandler
for a bidi streaming method of the service.
- asyncClientStreamingCall(ClientCall<ReqT, RespT>, StreamObserver<RespT>) - Static method in class io.grpc.stub.ClientCalls
-
Executes a client-streaming call returning a
StreamObserver
for the request messages.
- asyncClientStreamingCall(ServerCalls.ClientStreamingMethod<ReqT, RespT>) - Static method in class io.grpc.stub.ServerCalls
-
Creates a ServerCallHandler
for a client streaming method of the service.
- asyncServerStreamingCall(ClientCall<ReqT, RespT>, ReqT, StreamObserver<RespT>) - Static method in class io.grpc.stub.ClientCalls
-
- asyncServerStreamingCall(ServerCalls.ServerStreamingMethod<ReqT, RespT>) - Static method in class io.grpc.stub.ServerCalls
-
Creates a ServerCallHandler
for a server streaming method of the service.
- asyncUnaryCall(ClientCall<ReqT, RespT>, ReqT, StreamObserver<RespT>) - Static method in class io.grpc.stub.ClientCalls
-
- asyncUnaryCall(ServerCalls.UnaryMethod<ReqT, RespT>) - Static method in class io.grpc.stub.ServerCalls
-
Creates a ServerCallHandler
for a unary call method of the service.
- attach() - Method in class io.grpc.Context
-
Attach this context to the thread and make it
Context.current()
, the previously current context
will be restored when detach is called.
- attach() - Method in class io.grpc.Context.CancellableContext
-
- attachAsCloseable() - Method in class io.grpc.Context.CancellableContext
-
- attachHeaders(T, Metadata.Headers) - Static method in class io.grpc.stub.MetadataUtils
-
Attaches a set of request headers to a stub.
- augmentDescription(String) - Method in class io.grpc.Status
-
Create a derived instance of
Status
augmenting the current description with
additional detail.
- 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.
- awaitCompletion() - Method in class io.grpc.stub.StreamRecorder
-
Waits for the stream to terminate.
- awaitCompletion(int, TimeUnit) - Method in class io.grpc.stub.StreamRecorder
-
Waits a fixed timeout for the stream to terminate.
- awaitTermination(long, TimeUnit) - Method in class io.grpc.ChannelImpl
-
Waits for the channel to become terminated, giving up if the timeout is reached.
- awaitTermination(long, TimeUnit) - Method in class io.grpc.ServerImpl
-
Waits for the server to become terminated, giving up if the timeout is reached.
- awaitTermination() - Method in class io.grpc.ServerImpl
-
Waits for the server to become terminated.
- CallOptions - Class in io.grpc
-
The collection of runtime options for a new RPC call.
- callOptions - Variable in class io.grpc.stub.AbstractStub
-
- canBeCancelled() - Method in class io.grpc.Context.CancellableContext
-
- cancel() - Method in class io.grpc.ClientCall
-
Prevent any further processing for this ClientCall.
- cancel(Throwable) - Method in class io.grpc.Context.CancellableContext
-
Cancel this context and optionally provide a cause for the cancellation.
- cancel() - Method in class io.grpc.ForwardingClientCall
-
- cancel(Status) - Method in class io.grpc.internal.AbstractClientStream
-
Cancel the stream.
- cancel(Status) - Method in interface io.grpc.internal.ClientStream
-
Abnormally terminates the stream.
- cancel(Status) - Method in interface io.grpc.internal.ServerStream
-
Tears down the stream, typically in the event of a timeout.
- cancelled(Context) - Method in interface io.grpc.Context.CancellationListener
-
- CANCELLED - Static variable in class io.grpc.Status
-
The operation was cancelled (typically by the caller).
- canReceive() - Method in class io.grpc.internal.AbstractStream
-
Returns true
if the stream can receive data from its remote peer.
- canSend() - Method in class io.grpc.internal.AbstractStream
-
Returns true
if the stream can send data to its remote peer.
- captureMetadata(T, AtomicReference<Metadata.Headers>, AtomicReference<Metadata.Trailers>) - Static method in class io.grpc.stub.MetadataUtils
-
Captures the last received metadata for a stub.
- cause() - Method in class io.grpc.Context.CancellableContext
-
- cause() - Method in class io.grpc.Context
-
If a context
Context.isCancelled()
then return the cause of the cancellation or
null
if context was cancelled without a cause.
- Channel - Class in io.grpc
-
A Channel provides an abstraction over the transport layer that is designed to be consumed
by stub implementations.
- Channel() - Constructor for class io.grpc.Channel
-
- channel - Variable in class io.grpc.stub.AbstractStub
-
- ChannelEssentials(ClientTransportFactory, Runnable) - Constructor for class io.grpc.AbstractChannelBuilder.ChannelEssentials
-
Constructor.
- ChannelImpl - Class in io.grpc
-
A communication channel for making outgoing RPCs.
- channelInactive(ChannelHandlerContext) - Method in class io.grpc.netty.ProtocolNegotiators.AbstractBufferingHandler
-
- channelRegistered(ChannelHandlerContext) - Method in class io.grpc.netty.ProtocolNegotiators.AbstractBufferingHandler
-
- channelType(Class<? extends Channel>) - Method in class io.grpc.netty.NettyChannelBuilder
-
- channelType(Class<? extends ServerChannel>) - Method in class io.grpc.netty.NettyServerBuilder
-
- CheckedForwardingClientCall(ClientCall<ReqT, RespT>) - Constructor for class io.grpc.ClientInterceptors.CheckedForwardingClientCall
-
- checkedStart(ClientCall.Listener<RespT>, Metadata.Headers) - 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
-
- ClientAuthInterceptor - Class in io.grpc.auth
-
Client interceptor that authenticates all calls by binding header data provided by a credential.
- ClientAuthInterceptor(Credentials, Executor) - Constructor for class io.grpc.auth.ClientAuthInterceptor
-
- ClientCall<RequestT,ResponseT> - Class in io.grpc
-
An instance of a call to 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.
- ClientCalls - Class in io.grpc.stub
-
Utility functions for processing different call idioms.
- ClientCalls() - Constructor for class io.grpc.stub.ClientCalls
-
- 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
-
- 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.
- ClientTransport - Interface in io.grpc.internal
-
The client-side transport encapsulating a single connection to a remote server.
- ClientTransport.Listener - Interface in io.grpc.internal
-
Receives notifications for the transport life-cycle events.
- ClientTransport.PingCallback - Interface in io.grpc.internal
-
- ClientTransportFactory - Interface in io.grpc.internal
-
- close(Status, Metadata.Trailers) - Method in class io.grpc.ForwardingServerCall
-
- close() - Method in class io.grpc.internal.AbstractReadableBuffer
-
- close(Status, Metadata.Trailers) - Method in class io.grpc.internal.AbstractServerStream
-
- close() - Method in class io.grpc.internal.CompositeReadableBuffer
-
- close() - Method in class io.grpc.internal.ForwardingReadableBuffer
-
- close() - Method in class io.grpc.internal.MessageDeframer
-
Closes this deframer and frees any resources.
- 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.Trailers) - 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(ChannelHandlerContext, ChannelPromise) - Method in class io.grpc.netty.ProtocolNegotiators.AbstractBufferingHandler
-
- close(Status, Metadata.Trailers) - Method in class io.grpc.ServerCall
-
Close the call with the provided status.
- closed(Status, Metadata.Trailers) - 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() - Method in class io.grpc.internal.AbstractStream
-
Closes this deframer and frees any resources.
- code() - Method in enum io.grpc.internal.HttpUtil.Http2Error
-
Gets the code for this error used on the wire.
- CODE_KEY - Static variable in class io.grpc.Status
-
Key to bind status code to trailing metadata.
- complete() - Method in class io.grpc.internal.AbstractServerStream
-
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
-
- configure(SslContextBuilder) - Static method in class io.grpc.netty.GrpcSslContexts
-
Set ciphers and APN appropriate for gRPC.
- connectionSpec(ConnectionSpec) - Method in class io.grpc.okhttp.OkHttpChannelBuilder
-
For secure connection, provides a ConnectionSpec to specify Cipher suite and
TLS versions.
- containsKey(Metadata.Key<?>) - Method in class io.grpc.Metadata
-
Returns true if a value is defined for the given key.
- CONTENT_TYPE_GRPC - Static variable in class io.grpc.internal.HttpUtil
-
Content-Type used for GRPC-over-HTTP/2.
- CONTENT_TYPE_HEADER - Static variable in class io.grpc.okhttp.Headers
-
- CONTENT_TYPE_KEY - Static variable in class io.grpc.internal.HttpUtil
-
- Context - Class in io.grpc
-
A context propagation mechanism which carries deadlines, cancellation signals,
and other scoped values across API boundaries and between threads.
- Context.CancellableContext - Class in io.grpc
-
A context which inherits cancellation from its parent but which can also be independently
cancelled and which will propagate cancellation to its descendants.
- Context.CancellationListener - Interface in io.grpc
-
A listener notified on context cancellation.
- Context.Key<T> - Class in io.grpc
-
Key for indexing values stored in a context.
- create() - Method in interface io.grpc.internal.SharedResourceHolder.Resource
-
Create a new instance of the resource.
- create(MethodDescriptor.MethodType, String, String, MethodDescriptor.Marshaller<RequestT>, MethodDescriptor.Marshaller<ResponseT>) - Static method in class io.grpc.MethodDescriptor
-
Creates a new MethodDescriptor
.
- create(MethodDescriptor.MethodType, String, MethodDescriptor.Marshaller<RequestT>, MethodDescriptor.Marshaller<ResponseT>) - Static method in class io.grpc.MethodDescriptor
-
Creates a new MethodDescriptor
.
- create(MethodDescriptor<RequestT, ResponseT>, ServerCallHandler<RequestT, ResponseT>) - Static method in class io.grpc.ServerMethodDefinition
-
Create a new instance.
- create() - Static method in class io.grpc.stub.StreamRecorder
-
Creates a new recorder.
- createRequestHeaders(Metadata.Headers, String, String) - Static method in class io.grpc.okhttp.Headers
-
Serializes the given headers and creates a list of OkHttp
Header
s to be used when
creating a stream.
- current() - Static method in class io.grpc.Context
-
Return the context associated with the current thread, will never return
null
as
the
Context.ROOT
context is implicitly associated with all threads.
- 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.
- DEFAULT - Static variable in class io.grpc.CallOptions
-
A blank CallOptions
that all fields are not set.
- DEFAULT_CONNECTION_SPEC - Static variable in class io.grpc.okhttp.OkHttpChannelBuilder
-
- DEFAULT_FLOW_CONTROL_WINDOW - Static variable in class io.grpc.netty.NettyChannelBuilder
-
- DEFAULT_FLOW_CONTROL_WINDOW - Static variable in class io.grpc.netty.NettyServerBuilder
-
- DEFAULT_ONREADY_THRESHOLD - Static variable in class io.grpc.internal.AbstractStream
-
- deframe(ReadableBuffer, boolean) - Method in class io.grpc.internal.AbstractStream
-
Called to parse a received frame and attempt delivery of any completed
messages.
- deframe(ReadableBuffer, boolean) - Method in class io.grpc.internal.MessageDeframer
-
Adds the given data to this deframer and attempts delivery to the sink.
- deframeFailed(Throwable) - Method in class io.grpc.internal.AbstractClientStream
-
- deframeFailed(Throwable) - Method in class io.grpc.internal.AbstractServerStream
-
- deframeFailed(Throwable) - Method in class io.grpc.internal.AbstractStream
-
- delegate() - Method in class io.grpc.ClientInterceptors.CheckedForwardingClientCall
-
- 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
-
- deliverFrame(WritableBuffer, boolean, boolean) - Method in interface io.grpc.internal.MessageFramer.Sink
-
Delivers a frame via the transport.
- deliveryStalled() - Method in interface io.grpc.internal.MessageDeframer.Listener
-
Called when end-of-stream has not yet been reached but there are no complete messages
remaining to be delivered.
- detach() - Method in class io.grpc.Context.CancellableContext
-
- detach() - Method in class io.grpc.Context
-
Detach the current context from the thread and restore the context that was previously
attached to the thread as the 'current' context.
- detachAndCancel(Throwable) - Method in class io.grpc.Context.CancellableContext
-
Cancel this context and detach it from the current context from the thread and restore the
context that was previously attached to the thread as the 'current' context.
- dispose() - Method in class io.grpc.internal.AbstractStream
-
Frees any resources associated with this stream.
- dispose() - Method in class io.grpc.internal.MessageFramer
-
Closes the framer and releases any buffers, but does not flush.
- Drainable - Interface in io.grpc
-
- drainTo(OutputStream) - Method in interface io.grpc.Drainable
-
Transfers the entire contents of this stream to the specified target.
- fail(ChannelHandlerContext, Throwable) - Method in class io.grpc.netty.ProtocolNegotiators.AbstractBufferingHandler
-
- 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.
- firstValue() - Method in class io.grpc.stub.StreamRecorder
-
- flowControlWindow(int) - Method in class io.grpc.netty.NettyChannelBuilder
-
Sets the flow control window in bytes.
- flowControlWindow(int) - Method in class io.grpc.netty.NettyServerBuilder
-
Sets the HTTP/2 flow control window.
- flush() - Method in class io.grpc.internal.AbstractStream
-
- flush() - Method in class io.grpc.internal.MessageFramer
-
Flushes any buffered data in the framer to the sink.
- flush() - Method in interface io.grpc.internal.Stream
-
Flushes any internally buffered messages to the remote end-point.
- flush(ChannelHandlerContext) - Method in class io.grpc.netty.ProtocolNegotiators.AbstractBufferingHandler
-
- forAddress(SocketAddress) - Static method in class io.grpc.netty.NettyChannelBuilder
-
Creates a new builder with the given server address.
- forAddress(String, int) - Static method in class io.grpc.netty.NettyChannelBuilder
-
Creates a new builder with the given host and port.
- forAddress(SocketAddress) - Static method in class io.grpc.netty.NettyServerBuilder
-
Creates a server builder configured with the given
SocketAddress
.
- forAddress(String, int) - Static method in class io.grpc.okhttp.OkHttpChannelBuilder
-
Creates a new builder for the given server host and port.
- forClient() - Static method in class io.grpc.netty.GrpcSslContexts
-
Creates a SslContextBuilder with ciphers and APN appropriate for gRPC.
- forCode(long) - Static method in enum io.grpc.internal.HttpUtil.Http2Error
-
Looks up the HTTP/2 error code enum value for the specified code.
- fork() - Method in class io.grpc.Context
-
Create a new context which copies the values of this context but does not propagate its
cancellation and is its own independent root for cancellation.
- 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, HandlerRegistry) - Static method in class io.grpc.inprocess.InProcessServerBuilder
-
Create a server builder that will bind with the given name.
- forName(String) - Static method in class io.grpc.inprocess.InProcessServerBuilder
-
Create a server builder that will bind with the given name.
- forPort(int) - Static method in class io.grpc.netty.NettyServerBuilder
-
Creates a server builder that will bind to the given port.
- forRegistryAndPort(HandlerRegistry, int) - Static method in class io.grpc.netty.NettyServerBuilder
-
Creates a server builder that will bind to the given port and use the
HandlerRegistry
for call dispatching.
- forServer(File, File) - Static method in class io.grpc.netty.GrpcSslContexts
-
Creates a SslContextBuilder with ciphers and APN appropriate for gRPC.
- forServer(File, File, String) - Static method in class io.grpc.netty.GrpcSslContexts
-
Creates a SslContextBuilder with ciphers and APN appropriate for gRPC.
- 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
-
- ForwardingReadableBuffer - Class in io.grpc.internal
-
- ForwardingReadableBuffer(ReadableBuffer) - Constructor for class io.grpc.internal.ForwardingReadableBuffer
-
Constructor.
- ForwardingServerCall<RespT> - Class in io.grpc
-
- ForwardingServerCall() - Constructor for class io.grpc.ForwardingServerCall
-
- ForwardingServerCall.SimpleForwardingServerCall<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
-
- fromCodeValue(int) - Static method in class io.grpc.Status
-
- fromThrowable(Throwable) - Static method in class io.grpc.Status
-
- futureUnaryCall(ClientCall<ReqT, RespT>, ReqT) - Static method in class io.grpc.stub.ClientCalls
-
- generateFullMethodName(String, String) - Static method in class io.grpc.MethodDescriptor
-
Generate the fully qualified method name.
- get() - Method in class io.grpc.Context.Key
-
- get(Context) - Method in class io.grpc.Context.Key
-
Get the value from the specified context for this key.
- 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.
- 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.
- getAuthority() - Method in class io.grpc.Metadata.Headers
-
The serving authority for the operation.
- getCallOptions() - Method in class io.grpc.stub.AbstractStub
-
The CallOptions
of the stub.
- getCause() - Method in class io.grpc.Status
-
The underlying cause of an error.
- getChannel() - Method in class io.grpc.stub.AbstractStub
-
The underlying channel of the stub.
- getCode() - Method in class io.grpc.Status
-
The canonical status code.
- getDeadlineNanoTime() - Method in class io.grpc.CallOptions
-
- getDescription() - Method in class io.grpc.Status
-
A description of this status for human consumption.
- getError() - Method in class io.grpc.stub.StreamRecorder
-
Returns the stream terminating error.
- getFullMethodName() - Method in class io.grpc.MethodDescriptor
-
The fully qualified name of the method.
- getGrpcUserAgent(String, String) - Static method in class io.grpc.internal.HttpUtil
-
Gets the User-Agent string for the gRPC transport.
- getMethodDefinition() - Method in class io.grpc.HandlerRegistry.Method
-
- getMethodDescriptor() - Method in class io.grpc.ServerMethodDefinition
-
The MethodDescriptor
for this method.
- getMethods() - Method in class io.grpc.ServerServiceDefinition
-
- getName() - Method in class io.grpc.ServerServiceDefinition
-
Simple name of the service.
- getOnReadyThreshold() - Method in class io.grpc.internal.AbstractStream
-
- getPath() - Method in class io.grpc.Metadata.Headers
-
The path for the operation.
- getServerCallHandler() - Method in class io.grpc.ServerMethodDefinition
-
Handler for incoming calls.
- getServiceDefinition() - Method in class io.grpc.HandlerRegistry.Method
-
- getStatus() - Method in exception io.grpc.StatusException
-
- getStatus() - Method in exception io.grpc.StatusRuntimeException
-
- getType() - Method in class io.grpc.MethodDescriptor
-
The call type of the method.
- getValues() - Method in class io.grpc.stub.StreamRecorder
-
Returns the current set of received values.
- GrpcSslContexts - Class in io.grpc.netty
-
Utility for configuring SslContext for gRPC.
- halfClose() - Method in class io.grpc.ClientCall
-
Close the call for request message sending.
- halfClose() - Method in class io.grpc.ForwardingClientCall
-
- halfClose() - Method in class io.grpc.internal.AbstractClientStream
-
- halfClose() - Method in interface io.grpc.internal.ClientStream
-
Closes the local side of this stream and flushes any remaining messages.
- halfClosed() - Method in interface io.grpc.internal.ServerStreamListener
-
Called when the remote side of the transport gracefully closed, indicating the client had no
more data to send.
- HandlerRegistry - Class in io.grpc
-
Registry of services and their methods used by servers to dispatching incoming calls.
- HandlerRegistry() - Constructor for class io.grpc.HandlerRegistry
-
- HandlerRegistry.Method - Class in io.grpc
-
A method belonging to a service to be exposed to remote callers.
- hasArray() - Method in class io.grpc.internal.AbstractReadableBuffer
-
- hasArray() - Method in class io.grpc.internal.ForwardingReadableBuffer
-
- hasArray() - Method in interface io.grpc.internal.ReadableBuffer
-
Indicates whether or not this buffer exposes a backing array.
- hashCode() - Method in class io.grpc.Context.Key
-
- hashCode() - Method in class io.grpc.Metadata.Key
-
- Headers(byte[]...) - Constructor for class io.grpc.Metadata.Headers
-
Called by the transport layer to create headers from their binary serialized values.
- Headers() - Constructor for class io.grpc.Metadata.Headers
-
Called by the application layer to construct headers prior to passing them to the
transport for serialization.
- Headers - Class in io.grpc.okhttp
-
Constants for request/response headers.
- Headers() - Constructor for class io.grpc.okhttp.Headers
-
- headersRead(Metadata.Headers) - Method in interface io.grpc.internal.ClientStreamListener
-
Called upon receiving all header information from the remote end-point.
- Http2ClientStream - Class in io.grpc.internal
-
Base implementation for client streams using HTTP2 as the transport.
- Http2ClientStream(WritableBufferAllocator, ClientStreamListener) - Constructor for class io.grpc.internal.Http2ClientStream
-
- Http2Ping - Class in io.grpc.internal
-
Represents an outstanding PING operation on an HTTP/2 channel.
- Http2Ping(long, Stopwatch) - Constructor for class io.grpc.internal.Http2Ping
-
Creates a new ping operation.
- HTTP_METHOD - Static variable in class io.grpc.internal.HttpUtil
-
The HTTP method used for GRPC requests.
- httpStatusToGrpcStatus(int) - Static method in class io.grpc.internal.HttpUtil
-
Maps HTTP error response status codes to transport codes.
- HttpUtil - Class in io.grpc.internal
-
Constants for GRPC-over-HTTP (or HTTP/2).
- HttpUtil.Http2Error - Enum in io.grpc.internal
-
All error codes identified by the HTTP/2 spec.
- id() - Method in class io.grpc.internal.AbstractStream
-
Returns the internal ID for this stream.
- ignoreClose(ReadableBuffer) - Static method in class io.grpc.internal.ReadableBuffers
-
- inboundDataReceived(ReadableBuffer) - Method in class io.grpc.internal.AbstractClientStream
-
Processes the contents of a received data frame from the server.
- inboundDataReceived(ReadableBuffer, boolean) - Method in class io.grpc.internal.AbstractServerStream
-
Called in the network thread to process the content of an inbound DATA frame from the client.
- inboundDeliveryPaused() - Method in class io.grpc.internal.AbstractClientStream
-
- inboundDeliveryPaused() - Method in class io.grpc.internal.AbstractStream
-
Handles the event that the deframer has no pending deliveries.
- inboundHeadersReceived(Metadata.Headers) - Method in class io.grpc.internal.AbstractClientStream
-
Called by transport implementations when they receive headers.
- inboundTrailersReceived(Metadata.Trailers, Status) - Method in class io.grpc.internal.AbstractClientStream
-
Processes the trailers and status from the server.
- inboundTransportError(Status) - Method in class io.grpc.internal.AbstractClientStream
-
The transport implementation has detected a protocol error on the stream.
- 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.
- INTEGER_MARSHALLER - Static variable in class io.grpc.Metadata
-
Simple metadata marshaller that encodes an integer as a signed decimal string.
- intercept(List<ClientInterceptor>) - Method in class io.grpc.AbstractChannelBuilder
-
Adds interceptors that will be called before the channel performs its real work.
- intercept(ClientInterceptor...) - Method in class io.grpc.AbstractChannelBuilder
-
Adds interceptors that will be called before the channel performs its real work.
- 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(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(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
.
- interceptCall(MethodDescriptor<ReqT, RespT>, CallOptions, Channel) - Method in class io.grpc.auth.ClientAuthInterceptor
-
- interceptCall(MethodDescriptor<RequestT, ResponseT>, CallOptions, Channel) - Method in interface io.grpc.ClientInterceptor
-
- interceptCall(MethodDescriptor<RequestT, ResponseT>, ServerCall<ResponseT>, Metadata.Headers, ServerCallHandler<RequestT, ResponseT>) - Method in interface io.grpc.ServerInterceptor
-
- Internal - Annotation Type in io.grpc.internal
-
Annotates a program element which is internal to gRPC, not part of the public API, and should not
be used outside of gRPC codebase.
- INTERNAL - Static variable in class io.grpc.Status
-
Internal errors.
- internalSendFrame(WritableBuffer, boolean, boolean) - Method in class io.grpc.internal.AbstractClientStream
-
- internalSendFrame(WritableBuffer, boolean, boolean) - Method in class io.grpc.internal.AbstractServerStream
-
- internalSendFrame(WritableBuffer, boolean, boolean) - Method in class io.grpc.internal.AbstractStream
-
Sends an outbound frame to the remote end point.
- internalSendHeaders(Metadata.Headers) - Method in class io.grpc.internal.AbstractServerStream
-
Sends response headers to the remote end points.
- 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.auth - package io.grpc.auth
-
- 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 used inside gRPC.
- io.grpc.netty - package io.grpc.netty
-
The main transport implementation based on
Netty,
for both the client and the server.
- io.grpc.okhttp - package io.grpc.okhttp
-
A lightweight transport based on
OkHttp, mainly for use on Android
(client-only).
- io.grpc.protobuf - package io.grpc.protobuf
-
- io.grpc.protobuf.nano - package io.grpc.protobuf.nano
-
- io.grpc.stub - package io.grpc.stub
-
- isCancelled() - Method in class io.grpc.Context.CancellableContext
-
- isCancelled() - Method in class io.grpc.Context
-
Is this context cancelled.
- isCancelled() - Method in class io.grpc.ForwardingServerCall
-
- 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 class io.grpc.internal.AbstractClientStream
-
- isClosed() - Method in class io.grpc.internal.AbstractServerStream
-
- isClosed() - Method in class io.grpc.internal.AbstractStream
-
Whether the stream is fully 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
-
- isCurrent() - Method in class io.grpc.Context.CancellableContext
-
- isDeframerStalled() - Method in class io.grpc.internal.AbstractStream
-
Indicates whether delivery is currently stalled, pending receipt of more data.
- isOk() - Method in class io.grpc.Status
-
Is this status OK, i.e., not an error.
- 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.ForwardingClientCall
-
- isReady() - Method in class io.grpc.ForwardingServerCall
-
- isReady() - Method in class io.grpc.internal.AbstractStream
-
- 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.
- isShutdown() - Method in class io.grpc.ChannelImpl
-
Returns whether the channel is shutdown.
- isShutdown() - Method in class io.grpc.ServerImpl
-
Returns whether the server is shutdown.
- isStalled() - Method in class io.grpc.internal.MessageDeframer
-
Indicates whether delivery is currently stalled, pending receipt of more data.
- isTerminated() - Method in class io.grpc.ChannelImpl
-
Returns whether the channel is terminated.
- isTerminated() - Method in class io.grpc.ServerImpl
-
Returns whether the server is terminated.
- marshaller(Parser<T>) - Static method in class io.grpc.protobuf.nano.NanoUtils
-
Adapt parser
to a Marshaller
.
- marshaller(Parser<T>) - Static method in class io.grpc.protobuf.ProtoUtils
-
Adapt a Parser
to a Marshaller
.
- maxConcurrentCallsPerConnection(int) - Method in class io.grpc.netty.NettyServerBuilder
-
The maximum number of concurrent calls permitted for each incoming connection.
- merge(Metadata) - Method in class io.grpc.Metadata.Headers
-
- merge(Metadata, Set<Metadata.Key<?>>) - Method in class io.grpc.Metadata.Headers
-
- 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 for the given set of keys into this set of metadata.
- MESSAGE_KEY - Static variable in class io.grpc.Status
-
Key to bind status message to trailing metadata.
- MessageDeframer - Class in io.grpc.internal
-
Deframer for GRPC frames.
- MessageDeframer(MessageDeframer.Listener) - Constructor for class io.grpc.internal.MessageDeframer
-
Creates a deframer.
- MessageDeframer(MessageDeframer.Listener, MessageDeframer.Compression) - Constructor for class io.grpc.internal.MessageDeframer
-
Create a deframer.
- MessageDeframer.Compression - Enum in io.grpc.internal
-
- 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) - Constructor for class io.grpc.internal.MessageFramer
-
Creates a MessageFramer
without compression.
- MessageFramer(MessageFramer.Sink, WritableBufferAllocator, MessageFramer.Compression) - Constructor for class io.grpc.internal.MessageFramer
-
Creates a MessageFramer
.
- MessageFramer.Compression - Enum in io.grpc.internal
-
- MessageFramer.Sink - Interface in io.grpc.internal
-
Sink implemented by the transport layer to receive frames and forward them to their
destination.
- messageRead(InputStream) - Method in interface io.grpc.internal.MessageDeframer.Listener
-
Called to deliver the next complete message.
- messageRead(InputStream) - Method in interface io.grpc.internal.StreamListener
-
Called upon receiving a message from the remote end-point.
- Metadata - Class in io.grpc
-
Provides access to read and write metadata values to be exchanged during a call.
- Metadata.AsciiMarshaller<T> - Interface in io.grpc
-
Marshaller for metadata values that are serialized into ASCII strings that contain only
printable characters and space.
- Metadata.BinaryMarshaller<T> - Interface in io.grpc
-
Marshaller for metadata values that are serialized into raw binary.
- Metadata.Headers - Class in io.grpc
-
Concrete instance for metadata attached to the start of a call.
- Metadata.Key<T> - Class in io.grpc
-
Key for metadata entries.
- Metadata.Trailers - Class in io.grpc
-
Concrete instance for metadata attached to the end of the call.
- MetadataUtils - Class in io.grpc.stub
-
Utility functions for binding and receiving headers.
- MetadataUtils() - Constructor for class io.grpc.stub.MetadataUtils
-
- Method(ServerServiceDefinition, ServerMethodDefinition<?, ?>) - Constructor for class io.grpc.HandlerRegistry.Method
-
- METHOD_HEADER - Static variable in class io.grpc.okhttp.Headers
-
- MethodDescriptor<RequestT,ResponseT> - Class in io.grpc
-
Description of a remote method used by
Channel
to initiate a call.
- MethodDescriptor.Marshaller<T> - Interface in io.grpc
-
A typed abstraction over message parsing and serialization.
- MethodDescriptor.MethodType - Enum in io.grpc
-
The call type of a method.
- MutableHandlerRegistry - Class in io.grpc
-
- MutableHandlerRegistry() - Constructor for class io.grpc.MutableHandlerRegistry
-
- MutableHandlerRegistryImpl - Class in io.grpc
-
- MutableHandlerRegistryImpl() - Constructor for class io.grpc.MutableHandlerRegistryImpl
-
- name() - Method in class io.grpc.Metadata.Key
-
- NanoUtils - Class in io.grpc.protobuf.nano
-
Utility methods for using nano proto with grpc.
- NegotiationType - Enum in io.grpc.netty
-
Identifies the negotiation used for starting up HTTP/2.
- negotiationType(NegotiationType) - Method in class io.grpc.netty.NettyChannelBuilder
-
Sets the negotiation type for the HTTP/2 connection.
- NegotiationType - Enum in io.grpc.okhttp
-
Identifies the negotiation used for starting up HTTP/2.
- negotiationType(NegotiationType) - Method in class io.grpc.okhttp.OkHttpChannelBuilder
-
Sets the negotiation type for the HTTP/2 connection.
- NettyChannelBuilder - Class in io.grpc.netty
-
A builder to help simplify construction of channels using the Netty transport.
- NettyServer - Class in io.grpc.netty
-
Netty-based server implementation.
- NettyServerBuilder - Class in io.grpc.netty
-
A builder to help simplify the construction of a Netty-based GRPC server.
- newAttachHeadersInterceptor(Metadata.Headers) - Static method in class io.grpc.stub.MetadataUtils
-
Returns a client interceptor that attaches a set of headers to requests.
- newCall(MethodDescriptor<RequestT, ResponseT>) - Method in class io.grpc.Channel
-
- newCall(MethodDescriptor<RequestT, ResponseT>, CallOptions) - Method in class io.grpc.Channel
-
- newCall(MethodDescriptor<ReqT, RespT>, CallOptions) - Method in class io.grpc.ChannelImpl
-
- newCaptureMetadataInterceptor(AtomicReference<Metadata.Headers>, AtomicReference<Metadata.Trailers>) - Static method in class io.grpc.stub.MetadataUtils
-
Captures the last received metadata on a channel.
- newClientTransport() - Method in interface io.grpc.internal.ClientTransportFactory
-
Creates an unstarted transport for exclusive use.
- newHandler(Http2ConnectionHandler) - Method in interface io.grpc.netty.ProtocolNegotiator
-
Creates a new handler to control the protocol negotiation.
- newStream(MethodDescriptor<?, ?>, Metadata.Headers, ClientStreamListener) - Method in interface io.grpc.internal.ClientTransport
-
Creates a new stream for sending messages to the remote end-point.
- NOT_FOUND - Static variable in class io.grpc.Status
-
Some requested entity (e.g., file or directory) was not found.
- notifyFailed(ClientTransport.PingCallback, Executor, Throwable) - Static method in class io.grpc.internal.Http2Ping
-
Notifies the given callback that the ping operation failed.
- 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 a ASCII header.
- OK - Static variable in class io.grpc.Status
-
The operation completed successfully.
- OkHttpChannelBuilder - Class in io.grpc.okhttp
-
Convenience class for building channels with the OkHttp transport.
- onCancel() - Method in class io.grpc.ForwardingServerCallListener
-
- 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.Trailers) - Method in class io.grpc.ClientCall.Listener
-
The ClientCall has been closed.
- onClose(Status, Metadata.Trailers) - Method in class io.grpc.ForwardingClientCallListener
-
- onComplete() - Method in class io.grpc.ForwardingServerCallListener
-
- onComplete() - Method in class io.grpc.ServerCall.Listener
-
- onCompleted() - Method in interface io.grpc.stub.StreamObserver
-
Receives a notification of successful stream completion.
- onCompleted() - Method in class io.grpc.stub.StreamRecorder
-
- onError(Throwable) - Method in interface io.grpc.stub.StreamObserver
-
Receives a terminating error from the stream.
- onError(Throwable) - Method in class io.grpc.stub.StreamRecorder
-
- onHalfClose() - Method in class io.grpc.ForwardingServerCallListener
-
- onHalfClose() - Method in class io.grpc.ServerCall.Listener
-
The client completed all message sending.
- onHeaders(Metadata.Headers) - Method in class io.grpc.ClientCall.Listener
-
The response headers have been received.
- onHeaders(Metadata.Headers) - Method in class io.grpc.ForwardingClientCallListener
-
- 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(RequestT) - Method in class io.grpc.ServerCall.Listener
-
A request message has been received.
- onReady() - Method in class io.grpc.ClientCall.Listener
-
This indicates that the ClientCall is now capable of sending additional messages (via
ClientCall.sendMessage(RequestT)
) without requiring excessive buffering internally.
- onReady() - Method in class io.grpc.ForwardingClientCallListener
-
- onReady() - Method in class io.grpc.ForwardingServerCallListener
-
- 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
-
- 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
-
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.AbstractStream
-
Event handler to be called by the subclass when the stream's headers have passed any connection
flow control (i.e., MAX_CONCURRENT_STREAMS).
- onValue(V) - Method in interface io.grpc.stub.StreamObserver
-
Receives a value from the stream.
- onValue(T) - Method in class io.grpc.stub.StreamRecorder
-
- openStream(ReadableBuffer, boolean) - Static method in class io.grpc.internal.ReadableBuffers
-
- OUT_OF_RANGE - Static variable in class io.grpc.Status
-
Operation was attempted past the valid range.
- overrideHostForAuthority(String) - Method in class io.grpc.okhttp.OkHttpChannelBuilder
-
Overrides the host used with TLS and HTTP virtual hosting.
- 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.
- readUnsignedMedium() - Method in class io.grpc.internal.AbstractReadableBuffer
-
- readUnsignedMedium() - Method in class io.grpc.internal.ForwardingReadableBuffer
-
- readUnsignedMedium() - Method in interface io.grpc.internal.ReadableBuffer
-
Reads a 3-byte unsigned integer from this buffer using big-endian byte ordering.
- readUnsignedShort() - Method in class io.grpc.internal.AbstractReadableBuffer
-
- readUnsignedShort() - Method in class io.grpc.internal.ForwardingReadableBuffer
-
- readUnsignedShort() - Method in interface io.grpc.internal.ReadableBuffer
-
Reads a 2-byte unsigned integer from this buffer using big-endian byte ordering.
- receiveMessage(InputStream) - Method in class io.grpc.internal.AbstractClientStream
-
- receiveMessage(InputStream) - Method in class io.grpc.internal.AbstractServerStream
-
- receiveMessage(InputStream) - Method in class io.grpc.internal.AbstractStream
-
Handles a message that was just deframed.
- 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.
- remoteEndClosed() - Method in class io.grpc.internal.AbstractClientStream
-
- remoteEndClosed() - Method in class io.grpc.internal.AbstractServerStream
-
Called when the remote end half-closes the stream.
- remoteEndClosed() - Method in class io.grpc.internal.AbstractStream
-
Handles the event that the deframer has reached end of stream.
- remove(Metadata.Key<T>, T) - Method in class io.grpc.Metadata
-
Removes the first occurence of value for key.
- removeAll(Metadata.Key<T>) - Method in class io.grpc.Metadata
-
Remove all values for the given key.
- removeListener(Context.CancellationListener) - Method in class io.grpc.Context
-
- removeService(ServerServiceDefinition) - Method in class io.grpc.MutableHandlerRegistry
-
Returns false
if service
was not registered.
- removeService(ServerServiceDefinition) - Method in class io.grpc.MutableHandlerRegistryImpl
-
- request(int) - Method in class io.grpc.ClientCall
-
- request(int) - Method in class io.grpc.ForwardingClientCall
-
- request(int) - Method in class io.grpc.ForwardingServerCall
-
- request(int) - Method in class io.grpc.internal.MessageDeframer
-
- request(int) - Method in interface io.grpc.internal.Stream
-
- request(int) - Method in class io.grpc.ServerCall
-
- requestMessagesFromDeframer(int) - Method in class io.grpc.internal.AbstractStream
-
Called to request the given number of messages from the deframer.
- 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.
- returnProcessedBytes(int) - Method in class io.grpc.internal.AbstractStream
-
Returns the given number of processed bytes back to inbound flow control to enable receipt of
more data.
- ROOT - Static variable in class io.grpc.Context
-
- scheme() - Method in interface io.grpc.netty.ProtocolNegotiator.Handler
-
The HTTP/2 scheme to be used when sending HEADERS
.
- SCHEME_HEADER - Static variable in class io.grpc.okhttp.Headers
-
- sendCancel(Status) - Method in class io.grpc.internal.AbstractClientStream
-
Cancel the stream and send a stream cancellation message to the remote server, if necessary.
- sendFrame(WritableBuffer, boolean, boolean) - Method in class io.grpc.internal.AbstractClientStream
-
Sends an outbound frame to the remote end point.
- sendFrame(WritableBuffer, boolean, boolean) - Method in class io.grpc.internal.AbstractServerStream
-
Sends an outbound frame to the remote end point.
- sendHeaders(Metadata.Headers) - Method in class io.grpc.ForwardingServerCall
-
- sendHeaders(Metadata.Headers) - Method in class io.grpc.ServerCall
-
Send response header metadata prior to sending a response message.
- sendMessage(RequestT) - 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(ResponseT) - Method in class io.grpc.ServerCall
-
Send a response message.
- sendTrailers(Metadata.Trailers, boolean) - Method in class io.grpc.internal.AbstractServerStream
-
Sends trailers to the remote end point.
- serialize() - Method in class io.grpc.Metadata
-
Serialize all the metadata entries.
- 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 - Interface in io.grpc.internal
-
An object that accepts new incoming connections.
- Server - Class in io.grpc
-
Server for listening for and dispatching incoming calls.
- Server() - Constructor for class io.grpc.Server
-
- ServerCall<ResponseT> - Class in io.grpc
-
Encapsulates a single call received from a remote client.
- ServerCall() - Constructor for class io.grpc.ServerCall
-
- ServerCall.Listener<RequestT> - 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.
- ServerCalls - Class in io.grpc.stub
-
Utility functions for adapting
ServerCallHandler
s to application service implementation,
meant to be used by the generated code.
- ServerCalls.BidiStreamingMethod<ReqT,RespT> - Interface in io.grpc.stub
-
Adaptor to a bi-directional streaming method.
- ServerCalls.ClientStreamingMethod<ReqT,RespT> - Interface in io.grpc.stub
-
Adaptor to a client streaming method.
- ServerCalls.ServerStreamingMethod<ReqT,RespT> - Interface in io.grpc.stub
-
Adaptor to a server streaming method.
- ServerCalls.UnaryMethod<ReqT,RespT> - Interface in io.grpc.stub
-
Adaptor to a unary call method.
- ServerEssentials(Server, Runnable) - Constructor for class io.grpc.AbstractServerBuilder.ServerEssentials
-
Constructor.
- ServerImpl - Class in io.grpc
-
Default implementation of
Server
, for creation by transports.
- ServerImpl(Executor, HandlerRegistry, Server) - Constructor for class io.grpc.ServerImpl
-
Construct a server.
- ServerInterceptor - Interface in io.grpc
-
Interface for intercepting incoming calls before that are dispatched by
ServerCallHandler
.
- ServerInterceptors - Class in io.grpc
-
- ServerListener - Interface in io.grpc.internal
-
A listener to a server for transport creation events.
- ServerMethodDefinition<RequestT,ResponseT> - Class in io.grpc
-
- 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.
- 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.
- serverTls(SSLEngine) - Static method in class io.grpc.netty.ProtocolNegotiators
-
Create a TLS handler for HTTP/2 capable of using ALPN/NPN.
- ServerTransport - Interface in io.grpc.internal
-
An inbound connection.
- ServerTransportListener - Interface in io.grpc.internal
-
A observer of a server-side transport for stream creation events.
- setAuthority(String) - Method in class io.grpc.Metadata.Headers
-
Override the HTTP/2 authority the channel claims to be connecting to.
- setListener(ServerStreamListener) - Method in class io.grpc.internal.AbstractServerStream
-
Sets the listener to receive notifications.
- setPath(String) - Method in class io.grpc.Metadata.Headers
-
- 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.
- shutdown() - Method in class io.grpc.ChannelImpl
-
Initiates an orderly shutdown in which preexisting calls continue but new calls are immediately
cancelled.
- shutdown() - Method in interface io.grpc.internal.ClientTransport
-
Initiates an orderly shutdown of the transport.
- shutdown() - Method in interface io.grpc.internal.Server
-
Initiates an orderly shutdown of the server.
- shutdown() - Method in interface io.grpc.internal.ServerTransport
-
Initiates an orderly shutdown of the transport.
- shutdown() - Method in class io.grpc.netty.NettyServer
-
- shutdown() - Method in class io.grpc.ServerImpl
-
Initiates an orderly shutdown in which preexisting calls continue but new calls are rejected.
- shutdownNow() - Method in class io.grpc.ChannelImpl
-
Initiates a forceful shutdown in which preexisting and new calls are cancelled.
- shutdownNow() - Method in class io.grpc.ServerImpl
-
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<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.
- sslContext(SslContext) - Method in class io.grpc.netty.NettyChannelBuilder
-
SSL/TLS context to use instead of the system default.
- sslContext(SslContext) - Method in class io.grpc.netty.NettyServerBuilder
-
Sets the TLS context to use for encryption.
- sslSocketFactory(SSLSocketFactory) - Method in class io.grpc.okhttp.OkHttpChannelBuilder
-
Provides a SSLSocketFactory to replace the default SSLSocketFactory used for TLS.
- start(ClientCall.Listener<ResponseT>, Metadata.Headers) - Method in class io.grpc.ClientCall
-
Start a call, using responseListener
for processing response messages.
- start(ClientCall.Listener<RespT>, Metadata.Headers) - Method in class io.grpc.ClientInterceptors.CheckedForwardingClientCall
-
- start(ClientCall.Listener<RespT>, Metadata.Headers) - Method in class io.grpc.ForwardingClientCall
-
- start(ClientTransport.Listener) - Method in interface io.grpc.internal.ClientTransport
-
Starts transport.
- start(ServerListener) - Method in interface io.grpc.internal.Server
-
Starts transport.
- start(ServerListener) - Method in class io.grpc.netty.NettyServer
-
- start() - Method in class io.grpc.ServerImpl
-
Bind and start the server.
- startCall(MethodDescriptor<RequestT, ResponseT>, ServerCall<ResponseT>, Metadata.Headers) - Method in interface io.grpc.ServerCallHandler
-
Produce a non-null
listener for the incoming call.
- status() - Method in enum io.grpc.internal.HttpUtil.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
-
- statusForCode(long) - Static method in enum io.grpc.internal.HttpUtil.Http2Error
-
Looks up the
Status
from the given HTTP/2 error code.
- StatusRuntimeException - Exception in io.grpc
-
Status
in RuntimeException form, for propagating Status information via exceptions.
- StatusRuntimeException(Status) - Constructor for exception io.grpc.StatusRuntimeException
-
- 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.
- streamCreated(ServerStream, String, Metadata.Headers) - Method in interface io.grpc.internal.ServerTransportListener
-
Called when a new stream was created by the remote client.
- StreamListener - Interface in io.grpc.internal
-
- StreamObserver<V> - Interface in io.grpc.stub
-
Receives notifications from an observable stream of messages.
- StreamRecorder<T> - Class in io.grpc.stub
-
- streamRequest(RequestT) - Method in class io.grpc.MethodDescriptor
-
- streamResponse(ResponseT) - Method in class io.grpc.MethodDescriptor
-
Serialize an outgoing response message.
- TE_HEADER - Static variable in class io.grpc.okhttp.Headers
-
- TE_TRAILERS - Static variable in class io.grpc.internal.HttpUtil
-
The TE (transport encoding) header for requests over HTTP/2.
- TIMEOUT - Static variable in class io.grpc.internal.HttpUtil
-
The Timeout header name.
- TIMEOUT_KEY - Static variable in class io.grpc.ChannelImpl
-
Intended for internal use only.
- tls(SslContext, InetSocketAddress) - Static method in class io.grpc.netty.ProtocolNegotiators
-
Returns a
ProtocolNegotiator
that ensures the pipeline is set up so that TLS will
be negotiated, the
handler
is added and writes to the
Channel
may happen immediately, even before the TLS Handshake is complete.
- toAsciiString(T) - Method in interface io.grpc.Metadata.AsciiMarshaller
-
Serialize a metadata value to a ASCII string that contains only printable characters and
space.
- 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.
- toString() - Method in class io.grpc.CallOptions
-
- toString() - Method in class io.grpc.internal.AbstractStream
-
- toString() - Method in class io.grpc.Metadata.Headers
-
- toString() - Method in class io.grpc.Metadata.Key
-
- toString() - Method in class io.grpc.Metadata.Trailers
-
- toString() - Method in class io.grpc.Status
-
A string representation of the status useful for debugging.
- toStringHelper() - Method in class io.grpc.internal.AbstractClientStream
-
- toStringHelper() - Method in class io.grpc.internal.AbstractStream
-
- Trailers(byte[]...) - Constructor for class io.grpc.Metadata.Trailers
-
Called by the transport layer to create trailers from their binary serialized values.
- Trailers() - Constructor for class io.grpc.Metadata.Trailers
-
Called by the application layer to construct trailers prior to passing them to the
transport for serialization.
- 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.Http2ClientStream
-
Called by subclasses whenever a data frame is received from the transport.
- transportExecutor(ExecutorService) - Method in class io.grpc.okhttp.OkHttpChannelBuilder
-
Override the default executor necessary for internal transport use.
- TransportFrameUtil - Class in io.grpc.internal
-
Utility functions for transport layer framing.
- transportHeadersReceived(Metadata.Headers) - Method in class io.grpc.internal.Http2ClientStream
-
Called by subclasses whenever Headers
are received from the transport.
- transportReady() - Method in interface io.grpc.internal.ClientTransport.Listener
-
The transport is ready to accept traffic, because the connection is established.
- transportReportStatus(Status, boolean, Metadata.Trailers) - Method in class io.grpc.internal.AbstractClientStream
-
Report stream closure with status to the application layer if not already reported.
- transportShutdown(Status) - Method in interface io.grpc.internal.ClientTransport.Listener
-
The transport is shutting down.
- transportTerminated() - Method in interface io.grpc.internal.ClientTransport.Listener
-
The transport completed shutting down.
- transportTerminated() - Method in interface io.grpc.internal.ServerTransportListener
-
The transport completed shutting down.
- transportTrailersReceived(Metadata.Trailers) - Method in class io.grpc.internal.Http2ClientStream
-
Called by subclasses for the terminal trailer metadata on a stream.
- value() - Method in enum io.grpc.Status.Code
-
The numerical value of the code.
- valueOf(String) - Static method in enum io.grpc.internal.AbstractStream.Phase
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.grpc.internal.HttpUtil.Http2Error
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.grpc.internal.MessageDeframer.Compression
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.grpc.internal.MessageFramer.Compression
-
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.netty.NegotiationType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.grpc.okhttp.NegotiationType
-
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.internal.AbstractStream.Phase
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum io.grpc.internal.HttpUtil.Http2Error
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum io.grpc.internal.MessageDeframer.Compression
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum io.grpc.internal.MessageFramer.Compression
-
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.netty.NegotiationType
-
Returns an array containing the constants of this enum type, in
the order they are declared.
- values() - Static method in enum io.grpc.okhttp.NegotiationType
-
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.
- withCancellation() - Method in class io.grpc.Context
-
Create a new context which is independently cancellable and also cascades cancellation from
its parent.
- withCause(Throwable) - Method in class io.grpc.Status
-
Create a derived instance of
Status
with the given cause.
- withChannel(Channel) - Method in class io.grpc.stub.AbstractStub
-
Returns a new stub that uses the given channel.
- withDeadlineAfter(long, TimeUnit) - Method in class io.grpc.CallOptions
-
Returns a new CallOptions
with a deadline that is after the given duration
from
now.
- withDeadlineAfter(long, TimeUnit) - Method in class io.grpc.Context
-
Create a new context which will cancel itself after the given duration
from now.
- withDeadlineAfter(long, TimeUnit) - Method in class io.grpc.stub.AbstractStub
-
Returns a new stub with a deadline that is after the given duration
from now.
- withDeadlineNanoTime(Long) - Method in class io.grpc.CallOptions
-
Returns a new
CallOptions
with the given absolute deadline in nanoseconds in the clock
as per
System.nanoTime()
.
- withDeadlineNanoTime(long) - Method in class io.grpc.Context
-
Create a new context which will cancel itself after an absolute deadline expressed as
nanoseconds in the
System.nanoTime()
clock.
- withDeadlineNanoTime(Long) - Method in class io.grpc.stub.AbstractStub
-
Returns a new stub with an absolute deadline in nanoseconds in the clock as per
System.nanoTime()
.
- withDescription(String) - Method in class io.grpc.Status
-
Create a derived instance of
Status
with the given description.
- withInterceptors(ClientInterceptor...) - Method in class io.grpc.stub.AbstractStub
-
Returns a new stub that has the given interceptors attached to the underlying channel.
- withServerCallHandler(ServerCallHandler<RequestT, ResponseT>) - Method in class io.grpc.ServerMethodDefinition
-
Create a new method definition with a different call handler.
- withValue(Context.Key<V>, V) - Method in class io.grpc.Context
-
Create a new context with the given key value set.
- withValues(Context.Key<V1>, V1, Context.Key<V2>, V2) - Method in class io.grpc.Context
-
Create a new context with the given key value set.
- withValues(Context.Key<V1>, V1, Context.Key<V2>, V2, Context.Key<V3>, V3) - Method in class io.grpc.Context
-
Create a new context with the given key value set.
- workerEventLoopGroup(EventLoopGroup) - Method in class io.grpc.netty.NettyServerBuilder
-
Provides the worker EventGroupLoop to the server.
- wrap(Runnable) - Method in class io.grpc.Context
-
- wrap(Callable<C>) - Method in class io.grpc.Context
-
- 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
-
- 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(ChannelHandlerContext, Object, ChannelPromise) - Method in class io.grpc.netty.ProtocolNegotiators.AbstractBufferingHandler
-
- writeBufferedAndRemove(ChannelHandlerContext) - Method in class io.grpc.netty.ProtocolNegotiators.AbstractBufferingHandler
-
- writeHeaders(Metadata.Headers) - Method in class io.grpc.internal.AbstractServerStream
-
- writeHeaders(Metadata.Headers) - 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.AbstractServerStream
-
- writeMessage(InputStream) - Method in class io.grpc.internal.AbstractStream
-
- writeMessage(InputStream) - Method in interface io.grpc.internal.Stream
-
Writes a message payload to the remote end-point.
- writePayload(InputStream) - Method in class io.grpc.internal.MessageFramer
-
Writes out a payload message.