Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
A
- aborted - Variable in class io.grpc.stub.ClientCalls.CallToStreamObserverAdapter
- aborted - Variable in class io.grpc.stub.ServerCalls.ServerCallStreamObserverImpl
- ABORTED - Enum constant in enum io.grpc.Status.Code
-
The operation was aborted, typically due to a concurrency issue like sequencer check failures, transaction aborts, etc.
- 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.
- abruptGoAwayStatus - Variable in class io.grpc.netty.NettyClientHandler
- AbstractAsyncStub<S> - Class in io.grpc.stub
-
Stub implementations for async stubs.
- AbstractAsyncStub(Channel, CallOptions) - Constructor for class io.grpc.stub.AbstractAsyncStub
- AbstractBlockingStub<S> - Class in io.grpc.stub
-
Stub implementations for blocking stubs.
- AbstractBlockingStub(Channel, CallOptions) - Constructor for class io.grpc.stub.AbstractBlockingStub
- AbstractClientStream - Class in io.grpc.internal
-
The abstract base class for
ClientStream
implementations. - AbstractClientStream(WritableBufferAllocator, StatsTraceContext, TransportTracer, Metadata, CallOptions, boolean) - Constructor for class io.grpc.internal.AbstractClientStream
- AbstractClientStream.GetFramer - Class in io.grpc.internal
- 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 be called from the transport thread.
- abstractClientStreamSink() - Method in class io.grpc.internal.AbstractClientStream
-
Sink for transport to be called to perform outbound operations.
- abstractClientStreamSink() - Method in class io.grpc.netty.NettyClientStream
- AbstractFutureStub<S> - Class in io.grpc.stub
-
Stub implementations for future stubs.
- AbstractFutureStub(Channel, CallOptions) - Constructor for class io.grpc.stub.AbstractFutureStub
- AbstractHttp2Headers - Class in io.grpc.netty
- AbstractHttp2Headers() - Constructor for class io.grpc.netty.AbstractHttp2Headers
- AbstractNettyHandler - Class in io.grpc.netty
-
Base class for all Netty gRPC handlers.
- AbstractNettyHandler(ChannelPromise, Http2ConnectionDecoder, Http2ConnectionEncoder, Http2Settings, ChannelLogger, boolean, AbstractNettyHandler.PingLimiter, Ticker) - Constructor for class io.grpc.netty.AbstractNettyHandler
- AbstractNettyHandler.AllowPingLimiter - Class in io.grpc.netty
- AbstractNettyHandler.FlowControlPinger - Class in io.grpc.netty
-
Class for handling flow control pinging and flow control window updates as necessary.
- AbstractNettyHandler.PingLimiter - Interface in io.grpc.netty
-
Controls whether PINGs like those for BDP are permitted to be sent at the current time.
- AbstractQueuedCommand() - Constructor for class io.grpc.netty.WriteQueue.AbstractQueuedCommand
- AbstractReadableBuffer - Class in io.grpc.internal
-
Abstract base class for
ReadableBuffer
implementations. - AbstractReadableBuffer() - Constructor for class io.grpc.internal.AbstractReadableBuffer
- AbstractServerStream - Class in io.grpc.internal
-
Abstract base class for
ServerStream
implementations. - AbstractServerStream(WritableBufferAllocator, StatsTraceContext) - Constructor for class io.grpc.internal.AbstractServerStream
- AbstractServerStream.Sink - Interface in io.grpc.internal
-
A sink for outbound operations, separated from the stream simply to avoid name collisions/confusion.
- AbstractServerStream.TransportState - Class in io.grpc.internal
-
This should only be 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.
- abstractServerStreamSink() - Method in class io.grpc.netty.NettyServerStream
- abstractServerStreamSink() - Method in class io.grpc.servlet.jakarta.ServletServerStream
- abstractServerStreamSink() - Method in class io.grpc.servlet.ServletServerStream
- 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.
- AbstractStub<S> - 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.
- AbstractStub.StubFactory<T> - Interface in io.grpc.stub
-
A factory class for stub.
- AbstractSubchannel - Class in io.grpc.internal
-
The base interface of the Subchannels returned by
LoadBalancer.Helper.createSubchannel(io.grpc.LoadBalancer.CreateSubchannelArgs)
. - AbstractSubchannel() - Constructor for class io.grpc.internal.AbstractSubchannel
- accept(MetricRecorder.BatchRecorder) - Method in interface io.grpc.MetricRecorder.BatchCallback
-
Records instrument values into
recorder
. - ACCEPT_ENCODING_JOINER - Static variable in class io.grpc.DecompressorRegistry
- ACCEPT_ENCODING_SPLITTER - Static variable in class io.grpc.internal.GrpcUtil
- AcceptEncodingMarshaller() - Constructor for class io.grpc.internal.GrpcUtil.AcceptEncodingMarshaller
- acceptResolvedAddresses(LoadBalancer.ResolvedAddresses) - Method in class io.grpc.grpclb.GrpclbLoadBalancer
- acceptResolvedAddresses(LoadBalancer.ResolvedAddresses) - Method in class io.grpc.internal.AutoConfiguredLoadBalancerFactory.NoopLoadBalancer
- acceptResolvedAddresses(LoadBalancer.ResolvedAddresses) - Method in class io.grpc.internal.PickFirstLeafLoadBalancer
- acceptResolvedAddresses(LoadBalancer.ResolvedAddresses) - Method in class io.grpc.internal.PickFirstLoadBalancer
- acceptResolvedAddresses(LoadBalancer.ResolvedAddresses) - Method in class io.grpc.LoadBalancer
-
Accepts newly resolved addresses from the name resolution system.
- acceptResolvedAddresses(LoadBalancer.ResolvedAddresses) - Method in class io.grpc.rls.RlsLoadBalancer
- acceptResolvedAddresses(LoadBalancer.ResolvedAddresses) - Method in class io.grpc.util.GracefulSwitchLoadBalancer
- acceptResolvedAddresses(LoadBalancer.ResolvedAddresses) - Method in class io.grpc.util.MultiChildLoadBalancer
-
Override to completely replace the default logic or to do additional activities.
- acceptResolvedAddresses(LoadBalancer.ResolvedAddresses) - Method in class io.grpc.util.OutlierDetectionLoadBalancer
- acceptResolvedAddressesInternal(LoadBalancer.ResolvedAddresses) - Method in class io.grpc.util.MultiChildLoadBalancer
-
This does the work to update the child map and calculate which children have been removed.
- AcceptResolvedAddrRetVal(Status, List<MultiChildLoadBalancer.ChildLbState>) - Constructor for class io.grpc.util.MultiChildLoadBalancer.AcceptResolvedAddrRetVal
- active_ - Variable in class io.grpc.channelz.v1.SocketOptionLinger
- active_ - Variable in class io.grpc.channelz.v1.SocketOptionLinger.Builder
- ACTIVE_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.SocketOptionLinger
- activeCallCounter - Variable in class io.grpc.util.OutlierDetectionLoadBalancer.EndpointTracker
- activeHedges - Variable in class io.grpc.internal.RetriableStream.State
-
Unmodifiable collection of all the active hedging substreams.
- activeRpc - Variable in class io.grpc.protobuf.services.HealthCheckingLoadBalancerFactory.HealthCheckState
- activeTransport - Variable in class io.grpc.internal.InternalSubchannel
-
The transport for new outgoing requests.
- activeVolume() - Method in class io.grpc.util.OutlierDetectionLoadBalancer.EndpointTracker
- adapter - Variable in class io.grpc.stub.ClientCalls.StreamObserverToCallListenerAdapter
- ADAPTIVE_CUMULATOR - Static variable in class io.grpc.netty.GrpcHttp2ConnectionHandler
- ADAPTIVE_CUMULATOR_COMPOSE_MIN_SIZE_DEFAULT - Static variable in class io.grpc.netty.GrpcHttp2ConnectionHandler
- AdaptiveThrottler - Class in io.grpc.rls
-
Implementation of
Throttler
that keeps track of recent history (the duration of which is specified to the constructor) and throttles requests at the client side based on the number of requests that the backend has accepted and the total number of requests generated. - AdaptiveThrottler(AdaptiveThrottler.Builder) - Constructor for class io.grpc.rls.AdaptiveThrottler
- AdaptiveThrottler.Builder - Class in io.grpc.rls
-
Builder for
AdaptiveThrottler
. - AdaptiveThrottler.TimeBasedAccumulator - Class in io.grpc.rls
- AdaptiveThrottler.TimeBasedAccumulator.Slot - Class in io.grpc.rls
-
Holds the data for each slot (amount and end timestamp).
- add(long) - Method in class io.grpc.internal.AtomicLongCounter
- add(long) - Method in interface io.grpc.internal.LongCounter
-
Adds the delta to this counter.
- add(long) - Method in class io.grpc.internal.ReflectionLongAdderCounter
- add(RetriableStream<?>) - Method in class io.grpc.internal.ManagedChannelImpl.UncommittedRetriableStreamsRegistry
-
Registers a RetriableStream and return null if not shutdown, otherwise just returns the shutdown Status.
- add(Headers<? extends CharSequence, ? extends CharSequence, ?>) - Method in class io.grpc.netty.AbstractHttp2Headers
- add(AsciiString, AsciiString) - Method in class io.grpc.netty.GrpcHttp2HeadersUtils.GrpcHttp2InboundHeaders
- add(CharSequence, CharSequence) - Method in class io.grpc.netty.AbstractHttp2Headers
- add(CharSequence, CharSequence) - Method in class io.grpc.netty.GrpcHttp2HeadersUtils.GrpcHttp2RequestHeaders
- add(CharSequence, CharSequence) - Method in class io.grpc.netty.GrpcHttp2HeadersUtils.GrpcHttp2ResponseHeaders
- add(CharSequence, CharSequence...) - Method in class io.grpc.netty.AbstractHttp2Headers
- add(CharSequence, Iterable<? extends CharSequence>) - Method in class io.grpc.netty.AbstractHttp2Headers
- add(Map<Long, T>, T) - Static method in class io.grpc.InternalChannelz
- addActiveHedge(RetriableStream.Substream) - Method in class io.grpc.internal.RetriableStream.State
- addAllCallsFinishedWithDrop(Iterable<? extends ClientStatsPerToken>) - Method in class io.grpc.lb.v1.ClientStats.Builder
-
The list of dropped calls.
- addAllChannel(Iterable<? extends Channel>) - Method in class io.grpc.channelz.v1.GetTopChannelsResponse.Builder
-
list of channels that the connection detail service knows about.
- addAllChannelRef(Iterable<? extends ChannelRef>) - Method in class io.grpc.channelz.v1.Channel.Builder
-
There are no ordering guarantees on the order of channel refs.
- addAllChannelRef(Iterable<? extends ChannelRef>) - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
There are no ordering guarantees on the order of channel refs.
- addAllEntry(Iterable<? extends MetadataEntry>) - Method in class io.grpc.binarylog.v1.Metadata.Builder
-
repeated .grpc.binarylog.v1.MetadataEntry entry = 1;
- addAllEvents(Iterable<? extends ChannelTraceEvent>) - Method in class io.grpc.channelz.v1.ChannelTrace.Builder
-
List of events that have occurred on this channel.
- addAllExtensionNumber(Iterable<? extends Integer>) - Method in class io.grpc.reflection.v1.ExtensionNumberResponse.Builder
-
repeated int32 extension_number = 2;
- addAllExtensionNumber(Iterable<? extends Integer>) - Method in class io.grpc.reflection.v1alpha.ExtensionNumberResponse.Builder
-
repeated int32 extension_number = 2;
- addAllFileDescriptorProto(Iterable<? extends ByteString>) - Method in class io.grpc.reflection.v1.FileDescriptorResponse.Builder
-
Serialized FileDescriptorProto messages.
- addAllFileDescriptorProto(Iterable<? extends ByteString>) - Method in class io.grpc.reflection.v1alpha.FileDescriptorResponse.Builder
-
Serialized FileDescriptorProto messages.
- addAllGrpcKeybuilders(Iterable<? extends GrpcKeyBuilder>) - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
Unordered specifications for constructing keys for gRPC requests.
- addAllHeaders(Iterable<? extends NameMatcher>) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
-
Extract keys from all listed headers.
- addAllHeaders(Iterable<? extends NameMatcher>) - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
-
List of headers to try to match.
- addAllHostPatterns(Iterable<String>) - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
-
host_pattern is an ordered list of host template patterns for the desired value.
- addAllHttpKeybuilders(Iterable<? extends HttpKeyBuilder>) - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
Ordered specifications for constructing keys for HTTP requests.
- addAllListenSocket(Iterable<? extends SocketRef>) - Method in class io.grpc.channelz.v1.Server.Builder
-
The sockets that the server is listening on.
- addAllMethods(Collection<MethodDescriptor<?, ?>>) - Method in class io.grpc.ServiceDescriptor.Builder
-
Currently not exposed.
- addAllNames(Iterable<? extends GrpcKeyBuilder.Name>) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
-
repeated .grpc.lookup.v1.GrpcKeyBuilder.Name names = 1;
- addAllNames(Iterable<String>) - Method in class io.grpc.lookup.v1.NameMatcher.Builder
-
Ordered list of names (headers or query parameter names) that can supply this value; the first one with a non-empty value is used.
- addAllOption(Iterable<? extends SocketOption>) - Method in class io.grpc.channelz.v1.SocketData.Builder
-
Socket options set on this socket.
- addAllPathPatterns(Iterable<String>) - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
-
path_pattern is an ordered list of path template patterns for the desired value.
- addAllQueryParameters(Iterable<? extends NameMatcher>) - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
-
List of query parameter names to try to match.
- addAllServer(Iterable<? extends Server>) - Method in class io.grpc.channelz.v1.GetServersResponse.Builder
-
list of servers that the connection detail service knows about.
- addAllServers(Iterable<? extends Server>) - Method in class io.grpc.lb.v1.ServerList.Builder
-
Contains a list of servers selected by the load balancer.
- addAllService(Iterable<? extends ServiceResponse>) - Method in class io.grpc.reflection.v1.ListServiceResponse.Builder
-
The information of each service may be expanded in the future, so we use ServiceResponse message to encapsulate it.
- addAllService(Iterable<? extends ServiceResponse>) - Method in class io.grpc.reflection.v1alpha.ListServiceResponse.Builder
-
The information of each service may be expanded in the future, so we use ServiceResponse message to encapsulate it.
- addAllSocketRef(Iterable<? extends SocketRef>) - Method in class io.grpc.channelz.v1.Channel.Builder
-
There are no ordering guarantees on the order of sockets.
- addAllSocketRef(Iterable<? extends SocketRef>) - Method in class io.grpc.channelz.v1.GetServerSocketsResponse.Builder
-
list of socket refs that the connection detail service knows about.
- addAllSocketRef(Iterable<? extends SocketRef>) - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
There are no ordering guarantees on the order of sockets.
- addAllSubchannelRef(Iterable<? extends SubchannelRef>) - Method in class io.grpc.channelz.v1.Channel.Builder
-
At most one of 'channel_ref+subchannel_ref' and 'socket' is set.
- addAllSubchannelRef(Iterable<? extends SubchannelRef>) - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
At most one of 'channel_ref+subchannel_ref' and 'socket' is set.
- addAllTargets(Iterable<String>) - Method in class io.grpc.lookup.v1.RouteLookupResponse.Builder
-
Prioritized list (best one first) of addressable entities to use for routing, using syntax requested by the request target_type.
- addAllValidTargets(Iterable<String>) - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
This is a list of all the possible targets that can be returned by the lookup service.
- addAndGet(long) - Method in class io.grpc.internal.RetriableStream.ChannelBufferMeter
- addBoolean(CharSequence, boolean) - Method in class io.grpc.netty.AbstractHttp2Headers
- addBuffer(ReadableBuffer) - Method in class io.grpc.internal.CompositeReadableBuffer
-
Adds a new
ReadableBuffer
at the end of the buffer list. - addByte(CharSequence, byte) - Method in class io.grpc.netty.AbstractHttp2Headers
- addCallback(ClientTransport.PingCallback, Executor) - Method in class io.grpc.internal.Http2Ping
-
Registers a callback that is invoked when the ping operation completes.
- addCallsFinishedWithDrop(int, ClientStatsPerToken) - Method in class io.grpc.lb.v1.ClientStats.Builder
-
The list of dropped calls.
- addCallsFinishedWithDrop(int, ClientStatsPerToken.Builder) - Method in class io.grpc.lb.v1.ClientStats.Builder
-
The list of dropped calls.
- addCallsFinishedWithDrop(ClientStatsPerToken) - Method in class io.grpc.lb.v1.ClientStats.Builder
-
The list of dropped calls.
- addCallsFinishedWithDrop(ClientStatsPerToken.Builder) - Method in class io.grpc.lb.v1.ClientStats.Builder
-
The list of dropped calls.
- addCallsFinishedWithDropBuilder() - Method in class io.grpc.lb.v1.ClientStats.Builder
-
The list of dropped calls.
- addCallsFinishedWithDropBuilder(int) - Method in class io.grpc.lb.v1.ClientStats.Builder
-
The list of dropped calls.
- addChannel(int, Channel) - Method in class io.grpc.channelz.v1.GetTopChannelsResponse.Builder
-
list of channels that the connection detail service knows about.
- addChannel(int, Channel.Builder) - Method in class io.grpc.channelz.v1.GetTopChannelsResponse.Builder
-
list of channels that the connection detail service knows about.
- addChannel(Channel) - Method in class io.grpc.channelz.v1.GetTopChannelsResponse.Builder
-
list of channels that the connection detail service knows about.
- addChannel(Channel.Builder) - Method in class io.grpc.channelz.v1.GetTopChannelsResponse.Builder
-
list of channels that the connection detail service knows about.
- addChannelBuilder() - Method in class io.grpc.channelz.v1.GetTopChannelsResponse.Builder
-
list of channels that the connection detail service knows about.
- addChannelBuilder(int) - Method in class io.grpc.channelz.v1.GetTopChannelsResponse.Builder
-
list of channels that the connection detail service knows about.
- addChannelRef(int, ChannelRef) - Method in class io.grpc.channelz.v1.Channel.Builder
-
There are no ordering guarantees on the order of channel refs.
- addChannelRef(int, ChannelRef) - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
There are no ordering guarantees on the order of channel refs.
- addChannelRef(int, ChannelRef.Builder) - Method in class io.grpc.channelz.v1.Channel.Builder
-
There are no ordering guarantees on the order of channel refs.
- addChannelRef(int, ChannelRef.Builder) - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
There are no ordering guarantees on the order of channel refs.
- addChannelRef(ChannelRef) - Method in class io.grpc.channelz.v1.Channel.Builder
-
There are no ordering guarantees on the order of channel refs.
- addChannelRef(ChannelRef) - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
There are no ordering guarantees on the order of channel refs.
- addChannelRef(ChannelRef.Builder) - Method in class io.grpc.channelz.v1.Channel.Builder
-
There are no ordering guarantees on the order of channel refs.
- addChannelRef(ChannelRef.Builder) - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
There are no ordering guarantees on the order of channel refs.
- addChannelRefBuilder() - Method in class io.grpc.channelz.v1.Channel.Builder
-
There are no ordering guarantees on the order of channel refs.
- addChannelRefBuilder() - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
There are no ordering guarantees on the order of channel refs.
- addChannelRefBuilder(int) - Method in class io.grpc.channelz.v1.Channel.Builder
-
There are no ordering guarantees on the order of channel refs.
- addChannelRefBuilder(int) - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
There are no ordering guarantees on the order of channel refs.
- addChar(CharSequence, char) - Method in class io.grpc.netty.AbstractHttp2Headers
- addClientSocket(InternalInstrumented<InternalChannelz.SocketStats>) - Method in class io.grpc.InternalChannelz
-
Adds a socket.
- addDouble(CharSequence, double) - Method in class io.grpc.netty.AbstractHttp2Headers
- addDoubleCounter(DoubleCounterMetricInstrument, double, List<String>, List<String>) - Method in class io.grpc.internal.MetricRecorderImpl
-
Records a double counter value.
- addDoubleCounter(DoubleCounterMetricInstrument, double, List<String>, List<String>) - Method in interface io.grpc.MetricRecorder
-
Adds a value for a double-precision counter metric instrument.
- addDoubleCounter(DoubleCounterMetricInstrument, double, List<String>, List<String>) - Method in interface io.grpc.MetricSink
-
Adds a value for a double-precision counter associated with specified metric instrument.
- addEntry(int, MetadataEntry) - Method in class io.grpc.binarylog.v1.Metadata.Builder
-
repeated .grpc.binarylog.v1.MetadataEntry entry = 1;
- addEntry(int, MetadataEntry.Builder) - Method in class io.grpc.binarylog.v1.Metadata.Builder
-
repeated .grpc.binarylog.v1.MetadataEntry entry = 1;
- addEntry(MetadataEntry) - Method in class io.grpc.binarylog.v1.Metadata.Builder
-
repeated .grpc.binarylog.v1.MetadataEntry entry = 1;
- addEntry(MetadataEntry.Builder) - Method in class io.grpc.binarylog.v1.Metadata.Builder
-
repeated .grpc.binarylog.v1.MetadataEntry entry = 1;
- addEntryBuilder() - Method in class io.grpc.binarylog.v1.Metadata.Builder
-
repeated .grpc.binarylog.v1.MetadataEntry entry = 1;
- addEntryBuilder(int) - Method in class io.grpc.binarylog.v1.Metadata.Builder
-
repeated .grpc.binarylog.v1.MetadataEntry entry = 1;
- addEvents(int, ChannelTraceEvent) - Method in class io.grpc.channelz.v1.ChannelTrace.Builder
-
List of events that have occurred on this channel.
- addEvents(int, ChannelTraceEvent.Builder) - Method in class io.grpc.channelz.v1.ChannelTrace.Builder
-
List of events that have occurred on this channel.
- addEvents(ChannelTraceEvent) - Method in class io.grpc.channelz.v1.ChannelTrace.Builder
-
List of events that have occurred on this channel.
- addEvents(ChannelTraceEvent.Builder) - Method in class io.grpc.channelz.v1.ChannelTrace.Builder
-
List of events that have occurred on this channel.
- addEventsBuilder() - Method in class io.grpc.channelz.v1.ChannelTrace.Builder
-
List of events that have occurred on this channel.
- addEventsBuilder(int) - Method in class io.grpc.channelz.v1.ChannelTrace.Builder
-
List of events that have occurred on this channel.
- addExtensionNumber(int) - Method in class io.grpc.reflection.v1.ExtensionNumberResponse.Builder
-
repeated int32 extension_number = 2;
- addExtensionNumber(int) - Method in class io.grpc.reflection.v1alpha.ExtensionNumberResponse.Builder
-
repeated int32 extension_number = 2;
- addFileDescriptorProto(ByteString) - Method in class io.grpc.reflection.v1.FileDescriptorResponse.Builder
-
Serialized FileDescriptorProto messages.
- addFileDescriptorProto(ByteString) - Method in class io.grpc.reflection.v1alpha.FileDescriptorResponse.Builder
-
Serialized FileDescriptorProto messages.
- addFloat(CharSequence, float) - Method in class io.grpc.netty.AbstractHttp2Headers
- addGrpcKeybuilders(int, GrpcKeyBuilder) - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
Unordered specifications for constructing keys for gRPC requests.
- addGrpcKeybuilders(int, GrpcKeyBuilder.Builder) - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
Unordered specifications for constructing keys for gRPC requests.
- addGrpcKeybuilders(GrpcKeyBuilder) - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
Unordered specifications for constructing keys for gRPC requests.
- addGrpcKeybuilders(GrpcKeyBuilder.Builder) - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
Unordered specifications for constructing keys for gRPC requests.
- addGrpcKeybuildersBuilder() - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
Unordered specifications for constructing keys for gRPC requests.
- addGrpcKeybuildersBuilder(int) - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
Unordered specifications for constructing keys for gRPC requests.
- addGzippedBytes(ReadableBuffer) - Method in class io.grpc.internal.GzipInflatingBuffer
-
Adds more gzipped data, which will be consumed only when needed to fulfill requests made via
GzipInflatingBuffer.inflateBytes(byte[], int, int)
. - addHeader(AsciiString, byte[], byte[]) - Method in class io.grpc.netty.GrpcHttp2HeadersUtils.GrpcHttp2InboundHeaders
- addHeaders(int, NameMatcher) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
-
Extract keys from all listed headers.
- addHeaders(int, NameMatcher) - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
-
List of headers to try to match.
- addHeaders(int, NameMatcher.Builder) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
-
Extract keys from all listed headers.
- addHeaders(int, NameMatcher.Builder) - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
-
List of headers to try to match.
- addHeaders(NameMatcher) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
-
Extract keys from all listed headers.
- addHeaders(NameMatcher) - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
-
List of headers to try to match.
- addHeaders(NameMatcher.Builder) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
-
Extract keys from all listed headers.
- addHeaders(NameMatcher.Builder) - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
-
List of headers to try to match.
- addHeadersBuilder() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
-
Extract keys from all listed headers.
- addHeadersBuilder() - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
-
List of headers to try to match.
- addHeadersBuilder(int) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
-
Extract keys from all listed headers.
- addHeadersBuilder(int) - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
-
List of headers to try to match.
- addHostPatterns(String) - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
-
host_pattern is an ordered list of host template patterns for the desired value.
- addHostPatternsBytes(ByteString) - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
-
host_pattern is an ordered list of host template patterns for the desired value.
- addHttpKeybuilders(int, HttpKeyBuilder) - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
Ordered specifications for constructing keys for HTTP requests.
- addHttpKeybuilders(int, HttpKeyBuilder.Builder) - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
Ordered specifications for constructing keys for HTTP requests.
- addHttpKeybuilders(HttpKeyBuilder) - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
Ordered specifications for constructing keys for HTTP requests.
- addHttpKeybuilders(HttpKeyBuilder.Builder) - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
Ordered specifications for constructing keys for HTTP requests.
- addHttpKeybuildersBuilder() - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
Ordered specifications for constructing keys for HTTP requests.
- addHttpKeybuildersBuilder(int) - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
Ordered specifications for constructing keys for HTTP requests.
- addInput(ByteBufAllocator, CompositeByteBuf, ByteBuf) - Method in class io.grpc.netty.NettyAdaptiveCumulator
- addInt(CharSequence, int) - Method in class io.grpc.netty.AbstractHttp2Headers
- additional_ - Variable in class io.grpc.channelz.v1.SocketOption
- additional_ - Variable in class io.grpc.channelz.v1.SocketOption.Builder
- ADDITIONAL_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.SocketOption
- additionalBuilder_ - Variable in class io.grpc.channelz.v1.SocketOption.Builder
- addListenAddress(SocketAddress) - Method in class io.grpc.netty.NettyServerBuilder
-
Adds an additional address for this server to listen on.
- addListener(Context.CancellationListener, Executor) - Method in class io.grpc.Context
-
Add a listener that will be notified when the context becomes cancelled.
- addListener(Context.CancellationListener, Executor) - Method in class io.grpc.Context.CancellableContext
- addListenerInternal(Context.ExecutableListener) - Method in class io.grpc.Context.CancellableContext
- addListenSocket(int, SocketRef) - Method in class io.grpc.channelz.v1.Server.Builder
-
The sockets that the server is listening on.
- addListenSocket(int, SocketRef.Builder) - Method in class io.grpc.channelz.v1.Server.Builder
-
The sockets that the server is listening on.
- addListenSocket(SocketRef) - Method in class io.grpc.channelz.v1.Server.Builder
-
The sockets that the server is listening on.
- addListenSocket(SocketRef.Builder) - Method in class io.grpc.channelz.v1.Server.Builder
-
The sockets that the server is listening on.
- addListenSocket(InternalInstrumented<InternalChannelz.SocketStats>) - Method in class io.grpc.InternalChannelz
- addListenSocketBuilder() - Method in class io.grpc.channelz.v1.Server.Builder
-
The sockets that the server is listening on.
- addListenSocketBuilder(int) - Method in class io.grpc.channelz.v1.Server.Builder
-
The sockets that the server is listening on.
- addListenSockets(List<InternalInstrumented<InternalChannelz.SocketStats>>) - Method in class io.grpc.InternalChannelz.ServerStats.Builder
-
Sets the listen sockets.
- addLong(CharSequence, long) - Method in class io.grpc.netty.AbstractHttp2Headers
- addLongCounter(LongCounterMetricInstrument, long, List<String>, List<String>) - Method in class io.grpc.internal.MetricRecorderImpl
-
Records a long counter value.
- addLongCounter(LongCounterMetricInstrument, long, List<String>, List<String>) - Method in interface io.grpc.MetricRecorder
-
Adds a value for a long valued counter metric instrument.
- addLongCounter(LongCounterMetricInstrument, long, List<String>, List<String>) - Method in interface io.grpc.MetricSink
-
Adds a value for a long valued counter metric associated with specified metric instrument.
- addMethod - Static variable in class io.grpc.internal.ReflectionLongAdderCounter
- addMethod(MethodDescriptor<?, ?>) - Method in class io.grpc.ServiceDescriptor.Builder
-
Adds a method to this service.
- 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.
- addMetricSink(ManagedChannelBuilder<T>, MetricSink) - Static method in class io.grpc.InternalManagedChannelBuilder
- addMetricSink(MetricSink) - Method in class io.grpc.ForwardingChannelBuilder2
- addMetricSink(MetricSink) - Method in class io.grpc.internal.ManagedChannelImplBuilder
- addMetricSink(MetricSink) - Method in class io.grpc.ManagedChannelBuilder
-
Adds a
MetricSink
for channel to use for configuring and recording metrics. - addNames(int, GrpcKeyBuilder.Name) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
-
repeated .grpc.lookup.v1.GrpcKeyBuilder.Name names = 1;
- addNames(int, GrpcKeyBuilder.Name.Builder) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
-
repeated .grpc.lookup.v1.GrpcKeyBuilder.Name names = 1;
- addNames(GrpcKeyBuilder.Name) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
-
repeated .grpc.lookup.v1.GrpcKeyBuilder.Name names = 1;
- addNames(GrpcKeyBuilder.Name.Builder) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
-
repeated .grpc.lookup.v1.GrpcKeyBuilder.Name names = 1;
- addNames(String) - Method in class io.grpc.lookup.v1.NameMatcher.Builder
-
Ordered list of names (headers or query parameter names) that can supply this value; the first one with a non-empty value is used.
- addNamesBuilder() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
-
repeated .grpc.lookup.v1.GrpcKeyBuilder.Name names = 1;
- addNamesBuilder(int) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
-
repeated .grpc.lookup.v1.GrpcKeyBuilder.Name names = 1;
- addNamesBytes(ByteString) - Method in class io.grpc.lookup.v1.NameMatcher.Builder
-
Ordered list of names (headers or query parameter names) that can supply this value; the first one with a non-empty value is used.
- addObject(CharSequence, Iterable<?>) - Method in class io.grpc.netty.AbstractHttp2Headers
- addObject(CharSequence, Object) - Method in class io.grpc.netty.AbstractHttp2Headers
- addObject(CharSequence, Object...) - Method in class io.grpc.netty.AbstractHttp2Headers
- addOption(int, SocketOption) - Method in class io.grpc.channelz.v1.SocketData.Builder
-
Socket options set on this socket.
- addOption(int, SocketOption.Builder) - Method in class io.grpc.channelz.v1.SocketData.Builder
-
Socket options set on this socket.
- addOption(SocketOption) - Method in class io.grpc.channelz.v1.SocketData.Builder
-
Socket options set on this socket.
- addOption(SocketOption.Builder) - Method in class io.grpc.channelz.v1.SocketData.Builder
-
Socket options set on this socket.
- addOption(LoadBalancer.CreateSubchannelArgs.Key<T>, T) - Method in class io.grpc.LoadBalancer.CreateSubchannelArgs.Builder
-
Add a custom option.
- addOption(String, boolean) - Method in class io.grpc.InternalChannelz.SocketOptions.Builder
- addOption(String, int) - Method in class io.grpc.InternalChannelz.SocketOptions.Builder
- addOption(String, String) - Method in class io.grpc.InternalChannelz.SocketOptions.Builder
- addOptionalLabel(String, String) - Method in class io.grpc.ClientStreamTracer
-
Information providing context to the call became available.
- addOptionalLabel(String, String) - Method in class io.grpc.internal.ForwardingClientStreamTracer
- addOptionalLabel(String, String) - Method in class io.grpc.internal.PickDetailsConsumerImpl
- addOptionalLabel(String, String) - Method in interface io.grpc.LoadBalancer.PickDetailsConsumer
-
Optional labels that provide context of how the pick was routed.
- addOptionalLabel(String, String) - Method in class io.grpc.util.ForwardingClientStreamTracer
- addOptionBuilder() - Method in class io.grpc.channelz.v1.SocketData.Builder
-
Socket options set on this socket.
- addOptionBuilder(int) - Method in class io.grpc.channelz.v1.SocketData.Builder
-
Socket options set on this socket.
- addPathPatterns(String) - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
-
path_pattern is an ordered list of path template patterns for the desired value.
- addPathPatternsBytes(ByteString) - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
-
path_pattern is an ordered list of path template patterns for the desired value.
- addProvider(LoadBalancerProvider) - Method in class io.grpc.LoadBalancerRegistry
- addProvider(ManagedChannelProvider) - Method in class io.grpc.ManagedChannelRegistry
- addProvider(NameResolverProvider) - Method in class io.grpc.NameResolverRegistry
- addProvider(ServerProvider) - Method in class io.grpc.ServerRegistry
- addQueryParameters(int, NameMatcher) - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
-
List of query parameter names to try to match.
- addQueryParameters(int, NameMatcher.Builder) - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
-
List of query parameter names to try to match.
- addQueryParameters(NameMatcher) - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
-
List of query parameter names to try to match.
- addQueryParameters(NameMatcher.Builder) - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
-
List of query parameter names to try to match.
- addQueryParametersBuilder() - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
-
List of query parameter names to try to match.
- addQueryParametersBuilder(int) - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
-
List of query parameter names to try to match.
- address - Variable in class io.grpc.inprocess.InProcessTransport
- address - Variable in class io.grpc.internal.ManagedChannelImplBuilder.DirectAddressNameResolverProvider
- address - Variable in class io.grpc.netty.ProtocolNegotiators.ProxyProtocolNegotiationHandler
- Address - Class in io.grpc.binarylog.v1
-
Address information
- Address - Class in io.grpc.channelz.v1
-
Address represents the address used to create the socket.
- Address() - Constructor for class io.grpc.binarylog.v1.Address
- Address() - Constructor for class io.grpc.channelz.v1.Address
- Address(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.binarylog.v1.Address
- Address(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.channelz.v1.Address
- address_ - Variable in class io.grpc.binarylog.v1.Address
- address_ - Variable in class io.grpc.binarylog.v1.Address.Builder
- address_ - Variable in class io.grpc.channelz.v1.Address
- address_ - Variable in class io.grpc.channelz.v1.Address.Builder
- ADDRESS_FIELD_NUMBER - Static variable in class io.grpc.binarylog.v1.Address
- ADDRESS_NOT_SET - Enum constant in enum io.grpc.channelz.v1.Address.AddressCase
- Address.AddressCase - Enum in io.grpc.channelz.v1
- Address.Builder - Class in io.grpc.binarylog.v1
-
Address information
- Address.Builder - Class in io.grpc.channelz.v1
-
Address represents the address used to create the socket.
- Address.OtherAddress - Class in io.grpc.channelz.v1
-
An address type not included above.
- Address.OtherAddress.Builder - Class in io.grpc.channelz.v1
-
An address type not included above.
- Address.OtherAddressOrBuilder - Interface in io.grpc.channelz.v1
- Address.TcpIpAddress - Class in io.grpc.channelz.v1
-
Protobuf type
grpc.channelz.v1.Address.TcpIpAddress
- Address.TcpIpAddress.Builder - Class in io.grpc.channelz.v1
-
Protobuf type
grpc.channelz.v1.Address.TcpIpAddress
- Address.TcpIpAddressOrBuilder - Interface in io.grpc.channelz.v1
- Address.Type - Enum in io.grpc.binarylog.v1
-
Protobuf enum
grpc.binarylog.v1.Address.Type
- Address.UdsAddress - Class in io.grpc.channelz.v1
-
A Unix Domain Socket address.
- Address.UdsAddress.Builder - Class in io.grpc.channelz.v1
-
A Unix Domain Socket address.
- Address.UdsAddressOrBuilder - Interface in io.grpc.channelz.v1
- AddressCase(int) - Constructor for enum io.grpc.channelz.v1.Address.AddressCase
- addressCase_ - Variable in class io.grpc.channelz.v1.Address
- addressCase_ - Variable in class io.grpc.channelz.v1.Address.Builder
- addresses - Variable in class io.grpc.grpclb.BackendAddressGroup
- addresses - Variable in class io.grpc.internal.DnsNameResolver.InternalResolutionResult
- addresses - Variable in class io.grpc.LoadBalancer.ResolvedAddresses
- addresses - Variable in class io.grpc.LoadBalancer.ResolvedAddresses.Builder
- addresses - Variable in class io.grpc.NameResolver.ResolutionResult.Builder
- addresses - Variable in class io.grpc.netty.NettyServer
- addresses - Variable in class io.grpc.rls.ChildLbResolvedAddressFactory
- addressesOrError - Variable in class io.grpc.NameResolver.ResolutionResult
- addressGroups - Variable in class io.grpc.internal.InternalSubchannel
-
A volatile accessor to
InternalSubchannel.getAddressGroups()
. - addressGroups - Variable in class io.grpc.internal.InternalSubchannel.Index
- addressGroups - Variable in class io.grpc.internal.ManagedChannelImpl.SubchannelImpl
- addressGroups - Variable in class io.grpc.internal.PickFirstLeafLoadBalancer.Index
- addressIndex - Variable in class io.grpc.internal.InternalSubchannel
-
The index of the address corresponding to pendingTransport/activeTransport, or at beginning if both are null.
- addressIndex - Variable in class io.grpc.internal.InternalSubchannel.Index
- addressIndex - Variable in class io.grpc.internal.PickFirstLeafLoadBalancer
- addressIndex - Variable in class io.grpc.internal.PickFirstLeafLoadBalancer.Index
- addressMap - Variable in class io.grpc.util.OutlierDetectionLoadBalancer
- AddressOrBuilder - Interface in io.grpc.binarylog.v1
- AddressOrBuilder - Interface in io.grpc.channelz.v1
- addressResolver - Variable in class io.grpc.internal.DnsNameResolver
- addRootChannel(InternalInstrumented<InternalChannelz.ChannelStats>) - Method in class io.grpc.InternalChannelz
-
Adds a root channel.
- addrs - Variable in class io.grpc.EquivalentAddressGroup
- addrs - Variable in class io.grpc.LoadBalancer.CreateSubchannelArgs
- addrs - Variable in class io.grpc.LoadBalancer.CreateSubchannelArgs.Builder
- addrs - Variable in class io.grpc.util.MultiChildLoadBalancer.Endpoint
- addServer(int, Server) - Method in class io.grpc.channelz.v1.GetServersResponse.Builder
-
list of servers that the connection detail service knows about.
- addServer(int, Server.Builder) - Method in class io.grpc.channelz.v1.GetServersResponse.Builder
-
list of servers that the connection detail service knows about.
- addServer(Server) - Method in class io.grpc.channelz.v1.GetServersResponse.Builder
-
list of servers that the connection detail service knows about.
- addServer(Server.Builder) - Method in class io.grpc.channelz.v1.GetServersResponse.Builder
-
list of servers that the connection detail service knows about.
- addServer(InternalInstrumented<InternalChannelz.ServerStats>) - Method in class io.grpc.InternalChannelz
-
Adds a server.
- addServerBuilder() - Method in class io.grpc.channelz.v1.GetServersResponse.Builder
-
list of servers that the connection detail service knows about.
- addServerBuilder(int) - Method in class io.grpc.channelz.v1.GetServersResponse.Builder
-
list of servers that the connection detail service knows about.
- addServers(int, Server) - Method in class io.grpc.lb.v1.ServerList.Builder
-
Contains a list of servers selected by the load balancer.
- addServers(int, Server.Builder) - Method in class io.grpc.lb.v1.ServerList.Builder
-
Contains a list of servers selected by the load balancer.
- addServers(Server) - Method in class io.grpc.lb.v1.ServerList.Builder
-
Contains a list of servers selected by the load balancer.
- addServers(Server.Builder) - Method in class io.grpc.lb.v1.ServerList.Builder
-
Contains a list of servers selected by the load balancer.
- addServersBuilder() - Method in class io.grpc.lb.v1.ServerList.Builder
-
Contains a list of servers selected by the load balancer.
- addServersBuilder(int) - Method in class io.grpc.lb.v1.ServerList.Builder
-
Contains a list of servers selected by the load balancer.
- addServerSocket(InternalInstrumented<InternalChannelz.ServerStats>, InternalInstrumented<InternalChannelz.SocketStats>) - Method in class io.grpc.InternalChannelz
-
Adds a server socket.
- addService(int, ServiceResponse) - Method in class io.grpc.reflection.v1.ListServiceResponse.Builder
-
The information of each service may be expanded in the future, so we use ServiceResponse message to encapsulate it.
- addService(int, ServiceResponse.Builder) - Method in class io.grpc.reflection.v1.ListServiceResponse.Builder
-
The information of each service may be expanded in the future, so we use ServiceResponse message to encapsulate it.
- addService(int, ServiceResponse) - Method in class io.grpc.reflection.v1alpha.ListServiceResponse.Builder
-
The information of each service may be expanded in the future, so we use ServiceResponse message to encapsulate it.
- addService(int, ServiceResponse.Builder) - Method in class io.grpc.reflection.v1alpha.ListServiceResponse.Builder
-
The information of each service may be expanded in the future, so we use ServiceResponse message to encapsulate it.
- addService(BindableService) - Method in class io.grpc.ForwardingServerBuilder
- addService(BindableService) - Method in class io.grpc.internal.ServerImplBuilder
- addService(BindableService) - Method in class io.grpc.ServerBuilder
-
Adds a service implementation to the handler registry.
- addService(BindableService) - Method in class io.grpc.util.MutableHandlerRegistry
-
Registers a service.
- addService(ServiceResponse) - Method in class io.grpc.reflection.v1.ListServiceResponse.Builder
-
The information of each service may be expanded in the future, so we use ServiceResponse message to encapsulate it.
- addService(ServiceResponse.Builder) - Method in class io.grpc.reflection.v1.ListServiceResponse.Builder
-
The information of each service may be expanded in the future, so we use ServiceResponse message to encapsulate it.
- addService(ServiceResponse) - Method in class io.grpc.reflection.v1alpha.ListServiceResponse.Builder
-
The information of each service may be expanded in the future, so we use ServiceResponse message to encapsulate it.
- addService(ServiceResponse.Builder) - Method in class io.grpc.reflection.v1alpha.ListServiceResponse.Builder
-
The information of each service may be expanded in the future, so we use ServiceResponse message to encapsulate it.
- addService(ServerServiceDefinition) - Method in class io.grpc.ForwardingServerBuilder
- addService(ServerServiceDefinition) - Method in class io.grpc.internal.InternalHandlerRegistry.Builder
- addService(ServerServiceDefinition) - Method in class io.grpc.internal.ServerImplBuilder
- addService(ServerServiceDefinition) - 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.
- addServiceBuilder() - Method in class io.grpc.reflection.v1.ListServiceResponse.Builder
-
The information of each service may be expanded in the future, so we use ServiceResponse message to encapsulate it.
- addServiceBuilder() - Method in class io.grpc.reflection.v1alpha.ListServiceResponse.Builder
-
The information of each service may be expanded in the future, so we use ServiceResponse message to encapsulate it.
- addServiceBuilder(int) - Method in class io.grpc.reflection.v1.ListServiceResponse.Builder
-
The information of each service may be expanded in the future, so we use ServiceResponse message to encapsulate it.
- addServiceBuilder(int) - Method in class io.grpc.reflection.v1alpha.ListServiceResponse.Builder
-
The information of each service may be expanded in the future, so we use ServiceResponse message to encapsulate it.
- addServices(List<ServerServiceDefinition>) - Method in class io.grpc.ServerBuilder
-
Adds a list of service implementations to the handler registry together.
- addShort(CharSequence, short) - Method in class io.grpc.netty.AbstractHttp2Headers
- addSocketRef(int, SocketRef) - Method in class io.grpc.channelz.v1.Channel.Builder
-
There are no ordering guarantees on the order of sockets.
- addSocketRef(int, SocketRef) - Method in class io.grpc.channelz.v1.GetServerSocketsResponse.Builder
-
list of socket refs that the connection detail service knows about.
- addSocketRef(int, SocketRef) - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
There are no ordering guarantees on the order of sockets.
- addSocketRef(int, SocketRef.Builder) - Method in class io.grpc.channelz.v1.Channel.Builder
-
There are no ordering guarantees on the order of sockets.
- addSocketRef(int, SocketRef.Builder) - Method in class io.grpc.channelz.v1.GetServerSocketsResponse.Builder
-
list of socket refs that the connection detail service knows about.
- addSocketRef(int, SocketRef.Builder) - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
There are no ordering guarantees on the order of sockets.
- addSocketRef(SocketRef) - Method in class io.grpc.channelz.v1.Channel.Builder
-
There are no ordering guarantees on the order of sockets.
- addSocketRef(SocketRef) - Method in class io.grpc.channelz.v1.GetServerSocketsResponse.Builder
-
list of socket refs that the connection detail service knows about.
- addSocketRef(SocketRef) - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
There are no ordering guarantees on the order of sockets.
- addSocketRef(SocketRef.Builder) - Method in class io.grpc.channelz.v1.Channel.Builder
-
There are no ordering guarantees on the order of sockets.
- addSocketRef(SocketRef.Builder) - Method in class io.grpc.channelz.v1.GetServerSocketsResponse.Builder
-
list of socket refs that the connection detail service knows about.
- addSocketRef(SocketRef.Builder) - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
There are no ordering guarantees on the order of sockets.
- addSocketRefBuilder() - Method in class io.grpc.channelz.v1.Channel.Builder
-
There are no ordering guarantees on the order of sockets.
- addSocketRefBuilder() - Method in class io.grpc.channelz.v1.GetServerSocketsResponse.Builder
-
list of socket refs that the connection detail service knows about.
- addSocketRefBuilder() - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
There are no ordering guarantees on the order of sockets.
- addSocketRefBuilder(int) - Method in class io.grpc.channelz.v1.Channel.Builder
-
There are no ordering guarantees on the order of sockets.
- addSocketRefBuilder(int) - Method in class io.grpc.channelz.v1.GetServerSocketsResponse.Builder
-
list of socket refs that the connection detail service knows about.
- addSocketRefBuilder(int) - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
There are no ordering guarantees on the order of sockets.
- addStatusToTrailers(Metadata, Status) - Method in class io.grpc.internal.AbstractServerStream
- addStreamTracerFactory(ServerStreamTracer.Factory) - Method in class io.grpc.ForwardingServerBuilder
- addStreamTracerFactory(ServerStreamTracer.Factory) - Method in class io.grpc.internal.ServerImplBuilder
- addStreamTracerFactory(ServerStreamTracer.Factory) - Method in class io.grpc.ServerBuilder
-
Adds a
ServerStreamTracer.Factory
to measure server-side traffic. - addSubchannel(InternalInstrumented<InternalChannelz.ChannelStats>) - Method in class io.grpc.InternalChannelz
-
Adds a subchannel.
- addSubchannel(OutlierDetectionLoadBalancer.OutlierDetectionSubchannel) - Method in class io.grpc.util.OutlierDetectionLoadBalancer.EndpointTracker
-
Adds a subchannel to the tracker, while assuring that the subchannel ejection status is updated to match the tracker's if needed.
- addSubchannelRef(int, SubchannelRef) - Method in class io.grpc.channelz.v1.Channel.Builder
-
At most one of 'channel_ref+subchannel_ref' and 'socket' is set.
- addSubchannelRef(int, SubchannelRef) - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
At most one of 'channel_ref+subchannel_ref' and 'socket' is set.
- addSubchannelRef(int, SubchannelRef.Builder) - Method in class io.grpc.channelz.v1.Channel.Builder
-
At most one of 'channel_ref+subchannel_ref' and 'socket' is set.
- addSubchannelRef(int, SubchannelRef.Builder) - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
At most one of 'channel_ref+subchannel_ref' and 'socket' is set.
- addSubchannelRef(SubchannelRef) - Method in class io.grpc.channelz.v1.Channel.Builder
-
At most one of 'channel_ref+subchannel_ref' and 'socket' is set.
- addSubchannelRef(SubchannelRef) - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
At most one of 'channel_ref+subchannel_ref' and 'socket' is set.
- addSubchannelRef(SubchannelRef.Builder) - Method in class io.grpc.channelz.v1.Channel.Builder
-
At most one of 'channel_ref+subchannel_ref' and 'socket' is set.
- addSubchannelRef(SubchannelRef.Builder) - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
At most one of 'channel_ref+subchannel_ref' and 'socket' is set.
- addSubchannelRefBuilder() - Method in class io.grpc.channelz.v1.Channel.Builder
-
At most one of 'channel_ref+subchannel_ref' and 'socket' is set.
- addSubchannelRefBuilder() - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
At most one of 'channel_ref+subchannel_ref' and 'socket' is set.
- addSubchannelRefBuilder(int) - Method in class io.grpc.channelz.v1.Channel.Builder
-
At most one of 'channel_ref+subchannel_ref' and 'socket' is set.
- addSubchannelRefBuilder(int) - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
At most one of 'channel_ref+subchannel_ref' and 'socket' is set.
- addTargets(String) - Method in class io.grpc.lookup.v1.RouteLookupResponse.Builder
-
Prioritized list (best one first) of addressable entities to use for routing, using syntax requested by the request target_type.
- addTargetsBytes(ByteString) - Method in class io.grpc.lookup.v1.RouteLookupResponse.Builder
-
Prioritized list (best one first) of addressable entities to use for routing, using syntax requested by the request target_type.
- addTimeMillis(CharSequence, long) - Method in class io.grpc.netty.AbstractHttp2Headers
- addTransportFilter(ClientTransportFilter) - Method in class io.grpc.ForwardingChannelBuilder2
- addTransportFilter(ClientTransportFilter) - Method in class io.grpc.internal.ManagedChannelImplBuilder
- addTransportFilter(ClientTransportFilter) - Method in class io.grpc.ManagedChannelBuilder
-
Adds a
ClientTransportFilter
. - addTransportFilter(ServerTransportFilter) - Method in class io.grpc.ForwardingServerBuilder
- addTransportFilter(ServerTransportFilter) - Method in class io.grpc.internal.ServerImplBuilder
- addTransportFilter(ServerTransportFilter) - Method in class io.grpc.ServerBuilder
-
Adds a
ServerTransportFilter
. - addValidTargets(String) - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
This is a list of all the possible targets that can be returned by the lookup service.
- addValidTargetsBytes(ByteString) - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
This is a list of all the possible targets that can be returned by the lookup service.
- adjustHealthCheck() - Method in class io.grpc.protobuf.services.HealthCheckingLoadBalancerFactory.HealthCheckState
- AdminInterface - Class in io.grpc.services
-
Admin Interface provides a class of services for exposing the overall state of gRPC activity in a given binary.
- AdminInterface() - Constructor for class io.grpc.services.AdminInterface
- advanceBuffer() - Method in class io.grpc.internal.CompositeReadableBuffer
-
Removes one buffer from the front and closes it.
- advanceBufferIfNecessary() - Method in class io.grpc.internal.CompositeReadableBuffer
-
If the current buffer is exhausted, removes and closes it.
- AdvancedTlsX509KeyManager - Class in io.grpc.util
-
AdvancedTlsX509KeyManager is an
X509ExtendedKeyManager
that allows users to configure advanced TLS features, such as private key and certificate chain reloading. - AdvancedTlsX509KeyManager() - Constructor for class io.grpc.util.AdvancedTlsX509KeyManager
- AdvancedTlsX509KeyManager.Closeable - Interface in io.grpc.util
-
Mainly used to avoid throwing IO Exceptions in java.io.Closeable.
- AdvancedTlsX509KeyManager.KeyInfo - Class in io.grpc.util
- AdvancedTlsX509KeyManager.LoadFilePathExecution - Class in io.grpc.util
- AdvancedTlsX509KeyManager.UpdateResult - Class in io.grpc.util
- AdvancedTlsX509TrustManager - Class in io.grpc.util
-
AdvancedTlsX509TrustManager is an
X509ExtendedTrustManager
that allows users to configure advanced TLS features, such as root certificate reloading and peer cert custom verification. - AdvancedTlsX509TrustManager(AdvancedTlsX509TrustManager.Verification, AdvancedTlsX509TrustManager.SslSocketAndEnginePeerVerifier) - Constructor for class io.grpc.util.AdvancedTlsX509TrustManager
- AdvancedTlsX509TrustManager.Builder - Class in io.grpc.util
-
Builds a new
AdvancedTlsX509TrustManager
. - AdvancedTlsX509TrustManager.Closeable - Interface in io.grpc.util
- AdvancedTlsX509TrustManager.LoadFilePathExecution - Class in io.grpc.util
- AdvancedTlsX509TrustManager.SslSocketAndEnginePeerVerifier - Interface in io.grpc.util
- AdvancedTlsX509TrustManager.Verification - Enum in io.grpc.util
-
The verification mode when authenticating the peer certificate.
- advertised - Variable in class io.grpc.DecompressorRegistry.DecompressorInfo
- advertisedDecompressors - Variable in class io.grpc.DecompressorRegistry
- advmss - Variable in class io.grpc.InternalChannelz.TcpInfo
- advmss - Variable in class io.grpc.InternalChannelz.TcpInfo.Builder
- after(long, TimeUnit) - Static method in class io.grpc.Deadline
-
Create a deadline that will expire at the specified offset based on the
system ticker
. - after(long, TimeUnit, Deadline.Ticker) - Static method in class io.grpc.Deadline
-
Create a deadline that will expire at the specified offset based on the given
Deadline.Ticker
. - aggregateState(ConnectivityState, ConnectivityState) - Static method in class io.grpc.util.MultiChildLoadBalancer
- ALL_EXTENSION_NUMBERS_OF_TYPE - Enum constant in enum io.grpc.reflection.v1.ServerReflectionRequest.MessageRequestCase
- ALL_EXTENSION_NUMBERS_OF_TYPE - Enum constant in enum io.grpc.reflection.v1alpha.ServerReflectionRequest.MessageRequestCase
- ALL_EXTENSION_NUMBERS_OF_TYPE_FIELD_NUMBER - Static variable in class io.grpc.reflection.v1.ServerReflectionRequest
- ALL_EXTENSION_NUMBERS_OF_TYPE_FIELD_NUMBER - Static variable in class io.grpc.reflection.v1alpha.ServerReflectionRequest
- ALL_EXTENSION_NUMBERS_RESPONSE - Enum constant in enum io.grpc.reflection.v1.ServerReflectionResponse.MessageResponseCase
- ALL_EXTENSION_NUMBERS_RESPONSE - Enum constant in enum io.grpc.reflection.v1alpha.ServerReflectionResponse.MessageResponseCase
- ALL_EXTENSION_NUMBERS_RESPONSE_FIELD_NUMBER - Static variable in class io.grpc.reflection.v1.ServerReflectionResponse
- ALL_EXTENSION_NUMBERS_RESPONSE_FIELD_NUMBER - Static variable in class io.grpc.reflection.v1alpha.ServerReflectionResponse
- allExtensionNumbersResponseBuilder_ - Variable in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
- allExtensionNumbersResponseBuilder_ - Variable in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
- allocate(int) - Method in interface io.grpc.internal.WritableBufferAllocator
-
Request a new
WritableBuffer
with the givencapacityHint
. - allocate(int) - Method in class io.grpc.netty.NettyWritableBufferAllocator
- allocate(Class<?>, String) - Static method in class io.grpc.InternalLogId
-
Creates a log id.
- allocate(String, String) - Static method in class io.grpc.InternalLogId
-
Creates a log id.
- allocated - Variable in class io.grpc.internal.AbstractStream.TransportState
-
Indicates the stream has been created on the connection.
- ALLOCATION_SITE_PROPERTY_NAME - Static variable in class io.grpc.internal.ManagedChannelOrphanWrapper.ManagedChannelReference
- allocationSite - Variable in class io.grpc.internal.ManagedChannelOrphanWrapper.ManagedChannelReference
- allocator - Variable in class io.grpc.netty.NettyWritableBufferAllocator
- allocator - Static variable in class io.grpc.netty.Utils.ByteBufAllocatorPreferDirectHolder
- allocator - Static variable in class io.grpc.netty.Utils.ByteBufAllocatorPreferHeapHolder
- allowedInstruments - Variable in class io.grpc.internal.MetricRecorderImpl.BatchRecorderImpl
- AllowPingLimiter() - Constructor for class io.grpc.netty.AbstractNettyHandler.AllowPingLimiter
- allProviders - Variable in class io.grpc.LoadBalancerRegistry
- allProviders - Variable in class io.grpc.ManagedChannelRegistry
- allProviders - Variable in class io.grpc.NameResolverRegistry
- allProviders - Variable in class io.grpc.ServerRegistry
- ALPN - Static variable in class io.grpc.netty.GrpcSslContexts
- ALREADY_EXISTS - Enum constant in enum io.grpc.Status.Code
-
Some entity that we attempted to create (e.g., file or directory) already exists.
- ALREADY_EXISTS - Static variable in class io.grpc.Status
-
Some entity that we attempted to create (e.g., file or directory) already exists.
- ALWAYS_INCLUDED_METADATA - Static variable in class io.grpc.protobuf.services.BinlogHelper
- Annotation semantics - Search tag in class io.grpc.Attributes
- Section
- AnonymousInProcessSocketAddress - Class in io.grpc.inprocess
-
Custom SocketAddress class for
InProcessTransport
, for a server which can only be referenced via this address instance. - AnonymousInProcessSocketAddress() - Constructor for class io.grpc.inprocess.AnonymousInProcessSocketAddress
-
Creates a new AnonymousInProcessSocketAddress.
- any - Variable in class io.grpc.InternalChannelz.OtherSecurity
- anyObjectInUse(Object...) - Method in class io.grpc.internal.InUseStateAggregator
-
Returns
true
if any of the given objects are in use. - anythingReceived - Variable in class io.grpc.grpclb.GrpclbClientLoadRecorder.StreamTracer
- append(Object) - Method in class io.grpc.internal.InsightBuilder
-
Appends a piece of information which is a plain string.
- appendKeyValue(String, Object) - Method in class io.grpc.internal.InsightBuilder
-
Appends a piece of information which is a key-value , which will be formatted into
"key=value"
. - appendNameAndValue(StringBuilder, CharSequence, CharSequence, boolean) - Static method in class io.grpc.netty.GrpcHttp2HeadersUtils.GrpcHttp2InboundHeaders
- appendTimeoutInsight(InsightBuilder) - Method in class io.grpc.inprocess.InProcessTransport.InProcessStream.InProcessClientStream
- appendTimeoutInsight(InsightBuilder) - Method in class io.grpc.internal.AbstractClientStream
- appendTimeoutInsight(InsightBuilder) - Method in interface io.grpc.internal.ClientStream
-
Append information that will be included in the locally generated DEADLINE_EXCEEDED errors to the given
InsightBuilder
, in order to tell the user about the state of the stream so that they can better diagnose the cause of the error. - appendTimeoutInsight(InsightBuilder) - Method in class io.grpc.internal.DelayedClientTransport.PendingStream
- appendTimeoutInsight(InsightBuilder) - Method in class io.grpc.internal.DelayedStream
- appendTimeoutInsight(InsightBuilder) - Method in class io.grpc.internal.FailingClientStream
- appendTimeoutInsight(InsightBuilder) - Method in class io.grpc.internal.ForwardingClientStream
- appendTimeoutInsight(InsightBuilder) - Method in class io.grpc.internal.NoopClientStream
- appendTimeoutInsight(InsightBuilder) - Method in class io.grpc.internal.RetriableStream
- appExecutor - Variable in class io.grpc.CompositeCallCredentials.WrappingMetadataApplier
- appExecutor - Variable in class io.grpc.internal.CallCredentialsApplyingTransportFactory
- ApplicationThreadDeframer - Class in io.grpc.internal
-
Sits between
AbstractStream.TransportState
andMessageDeframer
to deframe in the client thread. - ApplicationThreadDeframer(MessageDeframer.Listener, ApplicationThreadDeframer.TransportExecutor, MessageDeframer) - Constructor for class io.grpc.internal.ApplicationThreadDeframer
- ApplicationThreadDeframer.CloseableInitializingMessageProducer - Class in io.grpc.internal
- ApplicationThreadDeframer.InitializingMessageProducer - Class in io.grpc.internal
- ApplicationThreadDeframer.TransportExecutor - Interface in io.grpc.internal
- ApplicationThreadDeframerListener - Class in io.grpc.internal
-
Listener for when deframing on the application thread, which calls the real listener on the transport thread.
- ApplicationThreadDeframerListener(MessageDeframer.Listener, ApplicationThreadDeframerListener.TransportExecutor) - Constructor for class io.grpc.internal.ApplicationThreadDeframerListener
- ApplicationThreadDeframerListener.TransportExecutor - Interface in io.grpc.internal
- applicationUtilization - Variable in class io.grpc.services.MetricRecorder
- applicationUtilization - Variable in class io.grpc.services.MetricReport
- applicationUtilizationMetric - Variable in class io.grpc.services.CallMetricRecorder
- applierListener - Variable in class io.grpc.internal.CallCredentialsApplyingTransportFactory.CallCredentialsApplyingTransport
- appListener - Variable in class io.grpc.internal.ApplicationThreadDeframer
- appListener - Variable in class io.grpc.internal.MigratingThreadDeframer
- apply(Metadata) - Method in class io.grpc.CallCredentials.MetadataApplier
-
Called when headers are successfully generated.
- apply(Metadata) - Method in class io.grpc.CompositeCallCredentials.CombiningMetadataApplier
- apply(Metadata) - Method in class io.grpc.CompositeCallCredentials.WrappingMetadataApplier
- apply(Metadata) - Method in class io.grpc.internal.MetadataApplierImpl
- applyMethodConfig() - Method in class io.grpc.internal.ClientCallImpl
- applyRequestMetadata(CallCredentials.RequestInfo, Executor, CallCredentials.MetadataApplier) - Method in class io.grpc.CallCredentials
-
Pass the credential data to the given
CallCredentials.MetadataApplier
, which will propagate it to the request metadata. - applyRequestMetadata(CallCredentials.RequestInfo, Executor, CallCredentials.MetadataApplier) - Method in class io.grpc.CompositeCallCredentials
- args - Variable in class io.grpc.internal.DelayedClientTransport.PendingStream
- args - Variable in class io.grpc.internal.ManagedChannelImpl.SubchannelImpl
- Args(Integer, ProxyDetector, SynchronizationContext, NameResolver.ServiceConfigParser, ScheduledExecutorService, ChannelLogger, Executor, String) - Constructor for class io.grpc.NameResolver.Args
- 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.
- array() - Method in class io.grpc.internal.ReadableBuffers.ByteArrayWrapper
- array() - Method in class io.grpc.internal.ReadableBuffers.ByteReadableBufferWrapper
- array() - Method in class io.grpc.netty.NettyReadableBuffer
- 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.
- arrayOffset() - Method in class io.grpc.internal.ReadableBuffers.ByteArrayWrapper
- arrayOffset() - Method in class io.grpc.internal.ReadableBuffers.ByteReadableBufferWrapper
- arrayOffset() - Method in class io.grpc.netty.NettyReadableBuffer
- AS_LARGE_AS_INFINITE - Static variable in class io.grpc.netty.NettyChannelBuilder
- AS_LARGE_AS_INFINITE - Static variable in class io.grpc.netty.NettyServerBuilder
- asChannel() - Method in class io.grpc.internal.ManagedChannelImpl.SubchannelImpl
- asChannel() - Method in class io.grpc.LoadBalancer.Subchannel
-
(Internal use only) returns a
Channel
that is backed by this Subchannel. - asChannel() - Method in class io.grpc.util.ForwardingSubchannel
- ASCII_STRING_MARSHALLER - Static variable in class io.grpc.Metadata
-
Simple metadata marshaller that encodes strings as is.
- AsciiKey(String, boolean, Metadata.AsciiMarshaller<T>) - Constructor for class io.grpc.Metadata.AsciiKey
-
Keys have a name and an ASCII marshaller used for serialization.
- asciiName() - Method in class io.grpc.Metadata.Key
-
Get the name as bytes using ASCII-encoding.
- asException() - Method in class io.grpc.Status
- asException(Metadata) - Method in class io.grpc.Status
-
Same as
Status.asException()
but includes the provided trailers in the returned exception. - asFactory() - Method in class io.grpc.NameResolverRegistry
- asRunnable(ClientTransport.PingCallback, long) - Static method in class io.grpc.internal.Http2Ping
-
Returns a runnable that, when run, invokes the given callback, providing the given round-trip duration.
- asRunnable(ClientTransport.PingCallback, Throwable) - Static method in class io.grpc.internal.Http2Ping
-
Returns a runnable that, when run, invokes the given callback, providing the given cause of failure.
- asRuntimeException() - Method in class io.grpc.Status
-
Convert this
Status
to aRuntimeException
. - asRuntimeException(Metadata) - Method in class io.grpc.Status
-
Same as
Status.asRuntimeException()
but includes the provided trailers in the returned exception. - asRuntimeException(Status, Metadata, boolean) - Static method in class io.grpc.InternalStatus
-
Create a new
StatusRuntimeException
with the internal option of skipping the filling of the stack trace. - assertEventLoopAndChannelType() - Method in class io.grpc.netty.NettyChannelBuilder
- assertEventLoopsAndChannelType() - Method in class io.grpc.netty.NettyServerBuilder
- assumedMessageSize - Variable in class io.grpc.inprocess.InProcessChannelBuilder
- assumedMessageSize - Variable in class io.grpc.inprocess.InProcessChannelBuilder.InProcessClientTransportFactory
- assumedMessageSize - Variable in class io.grpc.inprocess.InProcessTransport
- assumedMessageSize(long) - Method in class io.grpc.inprocess.InProcessChannelBuilder
-
Assumes RPC messages are the specified size.
- assureReadyAndDrainedTurnsFalse() - Method in class io.grpc.servlet.AsyncServletOutputStreamWriter
- assureReadyAndDrainedTurnsFalse() - Method in class io.grpc.servlet.jakarta.AsyncServletOutputStreamWriter
- ASYNC - Enum constant in enum io.grpc.stub.ClientCalls.StubType
- ASYNC - Enum constant in enum io.grpc.stub.InternalClientCalls.StubType
- asyncBidiStreamingCall(ClientCall<ReqT, RespT>, StreamObserver<RespT>) - Static method in class io.grpc.stub.ClientCalls
-
Executes a bidirectional-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. - asyncCtx - Variable in class io.grpc.servlet.jakarta.ServletAdapter.GrpcReadListener
- asyncCtx - Variable in class io.grpc.servlet.jakarta.ServletServerStream
- asyncCtx - Variable in class io.grpc.servlet.ServletAdapter.GrpcReadListener
- asyncCtx - Variable in class io.grpc.servlet.ServletServerStream
- asyncRlsCall(RlsProtoData.RouteLookupRequest, BackoffPolicy) - Method in class io.grpc.rls.CachingRlsLbClient
-
Populates async cache entry for new request.
- asyncServerStreamingCall(ClientCall<ReqT, RespT>, ReqT, StreamObserver<RespT>) - Static method in class io.grpc.stub.ClientCalls
-
Executes a server-streaming call with a response
StreamObserver
. - asyncServerStreamingCall(ServerCalls.ServerStreamingMethod<ReqT, RespT>) - Static method in class io.grpc.stub.ServerCalls
-
Creates a
ServerCallHandler
for a server streaming method of the service. - AsyncServletOutputStreamWriter - Class in io.grpc.servlet
-
Handles write actions from the container thread and the application thread.
- AsyncServletOutputStreamWriter - Class in io.grpc.servlet.jakarta
-
Handles write actions from the container thread and the application thread.
- AsyncServletOutputStreamWriter(AsyncContext, ServletServerStream.ServletTransportState, InternalLogId) - Constructor for class io.grpc.servlet.jakarta.AsyncServletOutputStreamWriter
- AsyncServletOutputStreamWriter(BiFunction<byte[], Integer, AsyncServletOutputStreamWriter.ActionItem>, AsyncServletOutputStreamWriter.ActionItem, AsyncServletOutputStreamWriter.ActionItem, BooleanSupplier, AsyncServletOutputStreamWriter.Log) - Constructor for class io.grpc.servlet.AsyncServletOutputStreamWriter
-
Constructor without java.util.logging and javax.servlet.* dependency, so that Lincheck can run.
- AsyncServletOutputStreamWriter(BiFunction<byte[], Integer, AsyncServletOutputStreamWriter.ActionItem>, AsyncServletOutputStreamWriter.ActionItem, AsyncServletOutputStreamWriter.ActionItem, BooleanSupplier, AsyncServletOutputStreamWriter.Log) - Constructor for class io.grpc.servlet.jakarta.AsyncServletOutputStreamWriter
-
Constructor without java.util.logging and jakarta.servlet.* dependency, so that Lincheck can run.
- AsyncServletOutputStreamWriter(AsyncContext, ServletServerStream.ServletTransportState, InternalLogId) - Constructor for class io.grpc.servlet.AsyncServletOutputStreamWriter
- AsyncServletOutputStreamWriter.ActionItem - Interface in io.grpc.servlet
-
Write actions, e.g.
- AsyncServletOutputStreamWriter.ActionItem - Interface in io.grpc.servlet.jakarta
-
Write actions, e.g.
- AsyncServletOutputStreamWriter.Log - Interface in io.grpc.servlet
- AsyncServletOutputStreamWriter.Log - Interface in io.grpc.servlet.jakarta
- AsyncServletOutputStreamWriter.WriteState - Class in io.grpc.servlet
- AsyncServletOutputStreamWriter.WriteState - Class in io.grpc.servlet.jakarta
- asyncStreamingRequestCall(ClientCall<ReqT, RespT>, StreamObserver<RespT>, boolean) - Static method in class io.grpc.stub.ClientCalls
- asyncUnaryCall(ClientCall<ReqT, RespT>, ReqT, StreamObserver<RespT>) - Static method in class io.grpc.stub.ClientCalls
-
Executes a unary call with a response
StreamObserver
. - asyncUnaryCall(ServerCalls.UnaryMethod<ReqT, RespT>) - Static method in class io.grpc.stub.ServerCalls
-
Creates a
ServerCallHandler
for a unary call method of the service. - asyncUnaryRequestCall(ClientCall<ReqT, RespT>, ReqT, ClientCalls.StartableListener<RespT>) - Static method in class io.grpc.stub.ClientCalls
- asyncUnaryRequestCall(ClientCall<ReqT, RespT>, ReqT, StreamObserver<RespT>, boolean) - Static method in class io.grpc.stub.ClientCalls
- asyncUnimplementedStreamingCall(MethodDescriptor<?, ?>, StreamObserver<?>) - Static method in class io.grpc.stub.ServerCalls
-
Sets unimplemented status for streaming call.
- asyncUnimplementedUnaryCall(MethodDescriptor<?, ?>, StreamObserver<?>) - Static method in class io.grpc.stub.ServerCalls
-
Sets unimplemented status for method on given response stream for unary call.
- ato - Variable in class io.grpc.InternalChannelz.TcpInfo
- ato - Variable in class io.grpc.InternalChannelz.TcpInfo.Builder
- ATOMIC_COUNT - Static variable in class io.grpc.rls.AdaptiveThrottler.TimeBasedAccumulator.Slot
- 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
- atomicHelper - Static variable in class io.grpc.internal.SerializingExecutor
- AtomicHelper() - Constructor for class io.grpc.internal.SerializingExecutor.AtomicHelper
- AtomicLongCounter - Class in io.grpc.internal
-
An implementation of
LongCounter
that is just anAtomicLong
. - AtomicLongCounter() - Constructor for class io.grpc.internal.AtomicLongCounter
-
Creates an
AtomicLongCounter
. - attach() - Method in class io.grpc.Context
-
Attach this context, thus enter a new scope within which this context is
Context.current()
. - attach() - Method in class io.grpc.Context.CancellableContext
- ATTR_AUTHORITY_OVERRIDE - Static variable in class io.grpc.EquivalentAddressGroup
-
The authority to be used when constructing Subchannels for this EquivalentAddressGroup.
- ATTR_CLIENT_EAG_ATTRS - Static variable in class io.grpc.internal.GrpcAttributes
-
Attribute key for the attributes of the
EquivalentAddressGroup
(EquivalentAddressGroup.getAttributes()
) that the transport's server address is from. - ATTR_HEALTH_CHECKING_CONFIG - Static variable in class io.grpc.LoadBalancer
- ATTR_LB_ADDR_AUTHORITY - Static variable in class io.grpc.grpclb.GrpclbConstants
-
The naming authority of a gRPC LB server address.
- ATTR_LB_ADDR_AUTHORITY - Static variable in class io.grpc.grpclb.InternalGrpclbConstantsAccessor
- ATTR_LB_ADDRS - Static variable in class io.grpc.grpclb.GrpclbConstants
-
Attribute key for gRPC LB server addresses.
- ATTR_LB_ADDRS - Static variable in class io.grpc.grpclb.InternalGrpclbConstantsAccessor
- ATTR_LB_PROVIDED_BACKEND - Static variable in class io.grpc.grpclb.GrpclbConstants
-
Whether this EquivalentAddressGroup was provided by a GRPCLB server.
- ATTR_SECURITY_LEVEL - Static variable in class io.grpc.internal.GrpcAttributes
-
The security level of the transport.
- attributes - Variable in class io.grpc.inprocess.InProcessTransport
- attributes - Variable in class io.grpc.internal.DnsNameResolver.InternalResolutionResult
- attributes - Variable in class io.grpc.internal.ServerCallInfoImpl
- attributes - Variable in class io.grpc.internal.ServerImpl.ServerTransportListenerImpl
- attributes - Variable in class io.grpc.LoadBalancer.ResolvedAddresses
- attributes - Variable in class io.grpc.LoadBalancer.ResolvedAddresses.Builder
- attributes - Variable in class io.grpc.NameResolver.ResolutionResult
- attributes - Variable in class io.grpc.NameResolver.ResolutionResult.Builder
- attributes - Variable in class io.grpc.netty.NettyClientHandler
- attributes - Variable in class io.grpc.netty.NettyServerHandler
-
Completed attributes produced by transportReady.
- attributes - Variable in class io.grpc.netty.NettyServerStream
- attributes - Variable in class io.grpc.netty.ProtocolNegotiationEvent
- attributes - Variable in class io.grpc.rls.ChildLbResolvedAddressFactory
- attributes - Variable in class io.grpc.servlet.jakarta.ServletAdapter
- attributes - Variable in class io.grpc.servlet.jakarta.ServletServerStream
- attributes - Variable in class io.grpc.servlet.ServletAdapter
- attributes - Variable in class io.grpc.servlet.ServletServerStream
- Attributes - Class in io.grpc
-
An immutable type-safe container of attributes.
- Attributes(IdentityHashMap<Attributes.Key<?>, Object>) - Constructor for class io.grpc.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.
- attrs - Variable in class io.grpc.EquivalentAddressGroup
- attrs - Variable in class io.grpc.LoadBalancer.CreateSubchannelArgs
- attrs - Variable in class io.grpc.LoadBalancer.CreateSubchannelArgs.Builder
- augmentDescription(String) - Method in class io.grpc.Status
-
Create a derived instance of
Status
augmenting the current description with additional detail. - authenticationProvider - Variable in class io.grpc.internal.ProxyDetectorImpl
- authority - Variable in class io.grpc.CallOptions
- authority - Variable in class io.grpc.CallOptions.Builder
- authority - Variable in class io.grpc.inprocess.InProcessTransport
- authority - Variable in class io.grpc.inprocess.InProcessTransport.InProcessStream
- authority - Variable in class io.grpc.internal.CallCredentialsApplyingTransportFactory.CallCredentialsApplyingTransport
- authority - Variable in class io.grpc.internal.ClientTransportFactory.ClientTransportOptions
- authority - Variable in class io.grpc.internal.DnsNameResolver
- authority - Variable in class io.grpc.internal.InternalSubchannel
- authority - Variable in class io.grpc.internal.ManagedChannelImpl.RealChannel
- authority - Variable in class io.grpc.internal.ManagedChannelImplBuilder.DirectAddressNameResolverProvider
- authority - Variable in class io.grpc.internal.OobChannel
- authority - Variable in class io.grpc.internal.ServerCallInfoImpl
- authority - Variable in class io.grpc.netty.GrpcHttp2HeadersUtils.GrpcHttp2RequestHeaders
- authority - Variable in class io.grpc.netty.NettyClientHandler
- authority - Variable in class io.grpc.netty.NettyClientStream
- authority - Variable in class io.grpc.netty.NettyClientTransport
- authority - Variable in class io.grpc.netty.NettyServerStream
- authority - Variable in class io.grpc.netty.ProtocolNegotiators.Http2UpgradeAndGrpcHandler
- authority - Variable in class io.grpc.netty.UdsNameResolver
- authority - Variable in class io.grpc.servlet.jakarta.ServletServerStream
- authority - Variable in class io.grpc.servlet.ServletServerStream
- authority() - Method in class io.grpc.Channel
-
The authority of the destination this channel connects to.
- authority() - Method in class io.grpc.ClientInterceptors.InterceptorChannel
- authority() - Method in class io.grpc.internal.ForwardingManagedChannel
- authority() - Method in class io.grpc.internal.ManagedChannelImpl
- authority() - Method in class io.grpc.internal.ManagedChannelImpl.RealChannel
- authority() - Method in class io.grpc.internal.OobChannel
- authority() - Method in class io.grpc.internal.SubchannelChannel
- authority() - Method in class io.grpc.netty.AbstractHttp2Headers
- authority() - Method in class io.grpc.netty.GrpcHttp2HeadersUtils.GrpcHttp2RequestHeaders
- authority(CharSequence) - Method in class io.grpc.netty.AbstractHttp2Headers
- authority_ - Variable in class io.grpc.binarylog.v1.ClientHeader
- authority_ - Variable in class io.grpc.binarylog.v1.ClientHeader.Builder
- AUTHORITY_DELIMS - Static variable in class io.grpc.internal.GrpcUtil.AuthorityEscaper
- AUTHORITY_FIELD_NUMBER - Static variable in class io.grpc.binarylog.v1.ClientHeader
- AUTHORITY_HEADER - Static variable in class io.grpc.netty.GrpcHttp2HeadersUtils.GrpcHttp2RequestHeaders
- authorityCheckerDisabled - Variable in class io.grpc.internal.ManagedChannelImplBuilder
- AuthorityEscaper() - Constructor for class io.grpc.internal.GrpcUtil.AuthorityEscaper
- authorityFromHostAndPort(String, int) - Static method in class io.grpc.Grpc
-
Combine a host and port into an authority string.
- authorityFromHostAndPort(String, int) - Static method in class io.grpc.internal.GrpcUtil
-
Combine a host and port into an authority string.
- authorityOverride - Variable in class io.grpc.internal.ManagedChannelImpl
- authorityOverride - Variable in class io.grpc.internal.ManagedChannelImplBuilder
- authorityString - Variable in class io.grpc.netty.NettyClientTransport
- authorityToUri(String) - Static method in class io.grpc.internal.GrpcUtil
-
Parse an authority into a URI for retrieving the host and port.
- AutoCleaningEvictionListener(LruCache.EvictionListener<RlsProtoData.RouteLookupRequest, CachingRlsLbClient.CacheEntry>) - Constructor for class io.grpc.rls.CachingRlsLbClient.AutoCleaningEvictionListener
- AutoConfiguredLoadBalancer(LoadBalancer.Helper) - Constructor for class io.grpc.internal.AutoConfiguredLoadBalancerFactory.AutoConfiguredLoadBalancer
- AutoConfiguredLoadBalancerFactory - Class in io.grpc.internal
- AutoConfiguredLoadBalancerFactory(LoadBalancerRegistry, String) - Constructor for class io.grpc.internal.AutoConfiguredLoadBalancerFactory
- AutoConfiguredLoadBalancerFactory(String) - Constructor for class io.grpc.internal.AutoConfiguredLoadBalancerFactory
- AutoConfiguredLoadBalancerFactory.AutoConfiguredLoadBalancer - Class in io.grpc.internal
- AutoConfiguredLoadBalancerFactory.EmptyPicker - Class in io.grpc.internal
- AutoConfiguredLoadBalancerFactory.FailingPicker - Class in io.grpc.internal
- AutoConfiguredLoadBalancerFactory.NoopLoadBalancer - Class in io.grpc.internal
- AutoConfiguredLoadBalancerFactory.PolicyException - Exception Class in io.grpc.internal
- autoFlowControl - Variable in class io.grpc.netty.NettyChannelBuilder
- autoFlowControl - Variable in class io.grpc.netty.NettyChannelBuilder.NettyTransportFactory
- autoFlowControl - Variable in class io.grpc.netty.NettyClientTransport
- autoFlowControl - Variable in class io.grpc.netty.NettyServer
- autoFlowControl - Variable in class io.grpc.netty.NettyServerBuilder
- autoFlowControl - Variable in class io.grpc.netty.NettyServerTransport
- autoLoadBalancerFactory - Variable in class io.grpc.internal.ScParser
- autoRequestEnabled - Variable in class io.grpc.stub.ClientCalls.CallToStreamObserverAdapter
- autoRequestEnabled - Variable in class io.grpc.stub.ServerCalls.ServerCallStreamObserverImpl
- autoTuneFlowControlOn - Variable in class io.grpc.netty.AbstractNettyHandler
- AutoValue_RlsProtoData_ExtraKeys - Class in io.grpc.rls
- AutoValue_RlsProtoData_ExtraKeys(String, String, String) - Constructor for class io.grpc.rls.AutoValue_RlsProtoData_ExtraKeys
- AutoValue_RlsProtoData_GrpcKeyBuilder - Class in io.grpc.rls
- AutoValue_RlsProtoData_GrpcKeyBuilder(ImmutableList<RlsProtoData.GrpcKeyBuilder.Name>, ImmutableList<RlsProtoData.NameMatcher>, RlsProtoData.ExtraKeys, ImmutableMap<String, String>) - Constructor for class io.grpc.rls.AutoValue_RlsProtoData_GrpcKeyBuilder
- AutoValue_RlsProtoData_GrpcKeyBuilder_Name - Class in io.grpc.rls
- AutoValue_RlsProtoData_GrpcKeyBuilder_Name(String, String) - Constructor for class io.grpc.rls.AutoValue_RlsProtoData_GrpcKeyBuilder_Name
- AutoValue_RlsProtoData_NameMatcher - Class in io.grpc.rls
- AutoValue_RlsProtoData_NameMatcher(String, ImmutableList<String>) - Constructor for class io.grpc.rls.AutoValue_RlsProtoData_NameMatcher
- AutoValue_RlsProtoData_RouteLookupConfig - Class in io.grpc.rls
- AutoValue_RlsProtoData_RouteLookupConfig(ImmutableList<RlsProtoData.GrpcKeyBuilder>, String, long, long, long, long, String) - Constructor for class io.grpc.rls.AutoValue_RlsProtoData_RouteLookupConfig
- AutoValue_RlsProtoData_RouteLookupConfig.Builder - Class in io.grpc.rls
- AutoValue_RlsProtoData_RouteLookupRequest - Class in io.grpc.rls
- AutoValue_RlsProtoData_RouteLookupRequest(ImmutableMap<String, String>) - Constructor for class io.grpc.rls.AutoValue_RlsProtoData_RouteLookupRequest
- AutoValue_RlsProtoData_RouteLookupResponse - Class in io.grpc.rls
- AutoValue_RlsProtoData_RouteLookupResponse(ImmutableList<String>, String) - Constructor for class io.grpc.rls.AutoValue_RlsProtoData_RouteLookupResponse
- available() - Method in class io.grpc.internal.ReadableBuffers.BufferInputStream
- 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.
- available() - Method in class io.grpc.protobuf.lite.ProtoInputStream
- awaitTermination() - Method in class io.grpc.internal.ServerImpl
- awaitTermination() - Method in class io.grpc.Server
-
Waits for the server to become terminated.
- awaitTermination(long, TimeUnit) - Method in class io.grpc.internal.ForwardingManagedChannel
- awaitTermination(long, TimeUnit) - Method in class io.grpc.internal.ManagedChannelImpl
- awaitTermination(long, TimeUnit) - Method in class io.grpc.internal.ManagedChannelImpl.RestrictedScheduledExecutor
- awaitTermination(long, TimeUnit) - Method in class io.grpc.internal.OobChannel
- awaitTermination(long, TimeUnit) - 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.
B
- BackendAddressGroup - Class in io.grpc.grpclb
- BackendAddressGroup(EquivalentAddressGroup, String) - Constructor for class io.grpc.grpclb.BackendAddressGroup
- BackendEntry(LoadBalancer.Subchannel) - Constructor for class io.grpc.grpclb.GrpclbState.BackendEntry
-
For ROUND_ROBIN/PICK_FIRST: creates a BackendEntry whose usage will not be reported.
- BackendEntry(LoadBalancer.Subchannel, GrpclbClientLoadRecorder, String) - Constructor for class io.grpc.grpclb.GrpclbState.BackendEntry
-
For ROUND_ROBIN: creates a BackendEntry whose usage will be reported to load recorder.
- BackendEntry(LoadBalancer.Subchannel, TokenAttachingTracerFactory) - Constructor for class io.grpc.grpclb.GrpclbState.BackendEntry
-
For PICK_FIRST: creates a BackendEntry that includes all addresses.
- backendList - Variable in class io.grpc.grpclb.GrpclbState
- backoff - Variable in class io.grpc.InternalChannelz.TcpInfo
- backoff - Variable in class io.grpc.InternalChannelz.TcpInfo.Builder
- backoff() - Method in class io.grpc.internal.AtomicBackoff.State
-
Causes future invocations of
AtomicBackoff.getState()
to have a value at least double this state's value. - backoffCacheEntry - Variable in class io.grpc.rls.CachingRlsLbClient.CachedRouteLookupResponse
- BackoffCacheEntry(RlsProtoData.RouteLookupRequest, Status, BackoffPolicy) - Constructor for class io.grpc.rls.CachingRlsLbClient.BackoffCacheEntry
- backoffEntry(CachingRlsLbClient.BackoffCacheEntry) - Static method in class io.grpc.rls.CachingRlsLbClient.CachedRouteLookupResponse
- backoffMultiplier - Variable in class io.grpc.internal.RetryPolicy
- backoffNanos - Variable in class io.grpc.internal.RetriableStream.RetryPlan
- backoffPolicy - Variable in class io.grpc.protobuf.services.HealthCheckingLoadBalancerFactory.HealthCheckState
- backoffPolicy - Variable in class io.grpc.rls.CachingRlsLbClient.BackoffCacheEntry
- backoffPolicy - Variable in class io.grpc.rls.CachingRlsLbClient.PendingCacheEntry
- BackoffPolicy - Interface in io.grpc.internal
-
Determines how long to wait before doing some action (typically a retry, or a reconnect).
- BackoffPolicy.Provider - Interface in io.grpc.internal
- backoffPolicyProvider - Variable in class io.grpc.grpclb.GrpclbLoadBalancer
- backoffPolicyProvider - Variable in class io.grpc.grpclb.GrpclbState
- backoffPolicyProvider - Variable in class io.grpc.internal.InternalSubchannel
- backoffPolicyProvider - Variable in class io.grpc.internal.ManagedChannelImpl
- backoffPolicyProvider - Variable in class io.grpc.protobuf.services.HealthCheckingLoadBalancerFactory
- BackoffPolicyRetryScheduler - Class in io.grpc.internal
-
Schedules a retry operation according to a
BackoffPolicy
. - BackoffPolicyRetryScheduler(BackoffPolicy.Provider, ScheduledExecutorService, SynchronizationContext) - Constructor for class io.grpc.internal.BackoffPolicyRetryScheduler
- backoffProvider - Variable in class io.grpc.rls.CachingRlsLbClient
- backoffProvider - Variable in class io.grpc.rls.CachingRlsLbClient.Builder
- BackoffRefreshListener() - Constructor for class io.grpc.rls.CachingRlsLbClient.BackoffRefreshListener
- balanceLoad(StreamObserver<LoadBalanceResponse>) - Method in interface io.grpc.lb.v1.LoadBalancerGrpc.AsyncService
-
Bidirectional rpc to get a list of servers.
- balanceLoad(StreamObserver<LoadBalanceResponse>) - Method in class io.grpc.lb.v1.LoadBalancerGrpc.LoadBalancerStub
-
Bidirectional rpc to get a list of servers.
- BALANCER_REQUESTED_FALLBACK_STATUS - Static variable in class io.grpc.grpclb.GrpclbState
- BALANCER_TIMEOUT_STATUS - Static variable in class io.grpc.grpclb.GrpclbState
- balancerRpcExecutorHolder - Variable in class io.grpc.internal.ManagedChannelImpl
- balancerRpcExecutorPool - Variable in class io.grpc.internal.ManagedChannelImpl
- balancerWorking - Variable in class io.grpc.grpclb.GrpclbState
- base - Variable in class io.grpc.Attributes.Builder
- BASE_TYPE_NAME_FIELD_NUMBER - Static variable in class io.grpc.reflection.v1.ExtensionNumberResponse
- BASE_TYPE_NAME_FIELD_NUMBER - Static variable in class io.grpc.reflection.v1alpha.ExtensionNumberResponse
- BASE64_ENCODING_OMIT_PADDING - Static variable in class io.grpc.InternalMetadata
-
An instance of base64 encoder that omits padding.
- BASE64_ENCODING_OMIT_PADDING - Static variable in class io.grpc.Metadata
- baseEjectionTimeNanos - Variable in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig
- baseEjectionTimeNanos - Variable in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig.Builder
- baseTypeName_ - Variable in class io.grpc.reflection.v1.ExtensionNumberResponse
- baseTypeName_ - Variable in class io.grpc.reflection.v1.ExtensionNumberResponse.Builder
- baseTypeName_ - Variable in class io.grpc.reflection.v1alpha.ExtensionNumberResponse
- baseTypeName_ - Variable in class io.grpc.reflection.v1alpha.ExtensionNumberResponse.Builder
- BatchRecorderImpl(MetricSink, BitSet) - Constructor for class io.grpc.internal.MetricRecorderImpl.BatchRecorderImpl
- BDP_MEASUREMENT_PING - Static variable in class io.grpc.netty.AbstractNettyHandler
- beforeStart(ClientCallStreamObserver<ReqT>) - Method in interface io.grpc.stub.ClientResponseObserver
-
Called by the runtime prior to the start of a call to provide a reference to the
ClientCallStreamObserver
for the outbound stream. - BEST_EFFORT_STATUS - Enum constant in enum io.grpc.netty.CancelServerStreamCommand.PeerNotify
-
Notify the peer about the
CancelServerStreamCommand.reason
by sending structured headers, if possible. - bidi - Variable in class io.grpc.stub.ServerCalls.StreamingServerCallHandler
- BIDI_STREAMING - Enum constant in enum io.grpc.MethodDescriptor.MethodType
-
Zero or more request and response messages arbitrarily interleaved in time.
- BINARY_BYTE_MARSHALLER - Static variable in class io.grpc.Metadata
-
Simple metadata marshaller that encodes bytes as is.
- BINARY_HEADER_SUFFIX - Static variable in class io.grpc.Metadata
-
All binary headers should have this suffix in their names.
- binaryHeaderSuffix - Static variable in class io.grpc.netty.GrpcHttp2HeadersUtils.GrpcHttp2InboundHeaders
- binaryHeaderSuffixBytes - Static variable in class io.grpc.internal.TransportFrameUtil
- BinaryKey(String, Metadata.BinaryMarshaller<T>) - Constructor for class io.grpc.Metadata.BinaryKey
-
Keys have a name and a binary marshaller used for serialization.
- BinaryLog - Class in io.grpc
-
A binary log that can be installed on a channel or server.
- BinaryLog() - Constructor for class io.grpc.BinaryLog
- BinaryLogProto - Class in io.grpc.binarylog.v1
- BinaryLogProto() - Constructor for class io.grpc.binarylog.v1.BinaryLogProto
- BinaryLogProvider - Class in io.grpc.protobuf.services
- BinaryLogProvider() - Constructor for class io.grpc.protobuf.services.BinaryLogProvider
- BinaryLogProvider.BinaryLogShim - Class in io.grpc.protobuf.services
-
The pipeline of interceptors is hard coded when the
ManagedChannel
is created. - BinaryLogProvider.ByteArrayMarshaller - Class in io.grpc.protobuf.services
- BinaryLogProvider.IoUtils - Class in io.grpc.protobuf.services
- BinaryLogProviderImpl - Class in io.grpc.protobuf.services
-
The default implementation of a
BinaryLogProvider
. - BinaryLogProviderImpl() - Constructor for class io.grpc.protobuf.services.BinaryLogProviderImpl
- BinaryLogProviderImpl(BinaryLogSink) - Constructor for class io.grpc.protobuf.services.BinaryLogProviderImpl
-
Deprecated.
- BinaryLogProviderImpl(BinaryLogSink, String) - Constructor for class io.grpc.protobuf.services.BinaryLogProviderImpl
-
Creates an instance.
- BinaryLogs - Class in io.grpc.protobuf.services
- BinaryLogs() - Constructor for class io.grpc.protobuf.services.BinaryLogs
- binaryLogShim - Variable in class io.grpc.protobuf.services.BinaryLogProvider
- BinaryLogShim() - Constructor for class io.grpc.protobuf.services.BinaryLogProvider.BinaryLogShim
- BinaryLogSink - Interface in io.grpc.protobuf.services
-
A class that accepts binary log messages.
- BindableService - Interface in io.grpc
-
Provides a way to bind instance of service implementation to server.
- bindService() - Method in interface io.grpc.BindableService
-
Creates
ServerServiceDefinition
object for current instance of service implementation. - bindService() - Method in class io.grpc.channelz.v1.ChannelzGrpc.ChannelzImplBase
- bindService() - Method in class io.grpc.health.v1.HealthGrpc.HealthImplBase
- bindService() - Method in class io.grpc.lb.v1.LoadBalancerGrpc.LoadBalancerImplBase
- bindService() - Method in class io.grpc.lookup.v1.RouteLookupServiceGrpc.RouteLookupServiceImplBase
- bindService() - Method in class io.grpc.protobuf.services.ProtoReflectionService
- bindService() - Method in class io.grpc.reflection.v1.ServerReflectionGrpc.ServerReflectionImplBase
- bindService() - Method in class io.grpc.reflection.v1alpha.ServerReflectionGrpc.ServerReflectionImplBase
- bindService(ChannelzGrpc.AsyncService) - Static method in class io.grpc.channelz.v1.ChannelzGrpc
- bindService(HealthGrpc.AsyncService) - Static method in class io.grpc.health.v1.HealthGrpc
- bindService(LoadBalancerGrpc.AsyncService) - Static method in class io.grpc.lb.v1.LoadBalancerGrpc
- bindService(RouteLookupServiceGrpc.AsyncService) - Static method in class io.grpc.lookup.v1.RouteLookupServiceGrpc
- bindService(ServerReflectionGrpc.AsyncService) - Static method in class io.grpc.reflection.v1.ServerReflectionGrpc
- bindService(ServerReflectionGrpc.AsyncService) - Static method in class io.grpc.reflection.v1alpha.ServerReflectionGrpc
- binlog - Variable in class io.grpc.internal.ManagedChannelImplBuilder
- binlog - Variable in class io.grpc.internal.ServerImpl
- binlog - Variable in class io.grpc.internal.ServerImplBuilder
- BinlogHelper - Class in io.grpc.protobuf.services
-
A binary log class that is configured for a specific
MethodDescriptor
. - BinlogHelper(BinlogHelper.SinkWriter) - Constructor for class io.grpc.protobuf.services.BinlogHelper
- BinlogHelper.Factory - Interface in io.grpc.protobuf.services
- BinlogHelper.FactoryImpl - Class in io.grpc.protobuf.services
- BinlogHelper.MaybeTruncated<T> - Class in io.grpc.protobuf.services
- BinlogHelper.SinkWriter - Class in io.grpc.protobuf.services
- BinlogHelper.SinkWriterImpl - Class in io.grpc.protobuf.services
- BinlogHelper.TimeProvider - Interface in io.grpc.protobuf.services
- bitField0_ - Variable in class io.grpc.binarylog.v1.Address.Builder
- bitField0_ - Variable in class io.grpc.binarylog.v1.ClientHeader
- bitField0_ - Variable in class io.grpc.binarylog.v1.ClientHeader.Builder
- bitField0_ - Variable in class io.grpc.binarylog.v1.GrpcLogEntry
- bitField0_ - Variable in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
- bitField0_ - Variable in class io.grpc.binarylog.v1.Message.Builder
- bitField0_ - Variable in class io.grpc.binarylog.v1.Metadata.Builder
- bitField0_ - Variable in class io.grpc.binarylog.v1.MetadataEntry.Builder
- bitField0_ - Variable in class io.grpc.binarylog.v1.ServerHeader
- bitField0_ - Variable in class io.grpc.binarylog.v1.ServerHeader.Builder
- bitField0_ - Variable in class io.grpc.binarylog.v1.Trailer
- bitField0_ - Variable in class io.grpc.binarylog.v1.Trailer.Builder
- bitField0_ - Variable in class io.grpc.channelz.v1.Address.Builder
- bitField0_ - Variable in class io.grpc.channelz.v1.Address.OtherAddress
- bitField0_ - Variable in class io.grpc.channelz.v1.Address.OtherAddress.Builder
- bitField0_ - Variable in class io.grpc.channelz.v1.Address.TcpIpAddress.Builder
- bitField0_ - Variable in class io.grpc.channelz.v1.Address.UdsAddress.Builder
- bitField0_ - Variable in class io.grpc.channelz.v1.Channel
- bitField0_ - Variable in class io.grpc.channelz.v1.Channel.Builder
- bitField0_ - Variable in class io.grpc.channelz.v1.ChannelConnectivityState.Builder
- bitField0_ - Variable in class io.grpc.channelz.v1.ChannelData
- bitField0_ - Variable in class io.grpc.channelz.v1.ChannelData.Builder
- bitField0_ - Variable in class io.grpc.channelz.v1.ChannelRef.Builder
- bitField0_ - Variable in class io.grpc.channelz.v1.ChannelTrace
- bitField0_ - Variable in class io.grpc.channelz.v1.ChannelTrace.Builder
- bitField0_ - Variable in class io.grpc.channelz.v1.ChannelTraceEvent
- bitField0_ - Variable in class io.grpc.channelz.v1.ChannelTraceEvent.Builder
- bitField0_ - Variable in class io.grpc.channelz.v1.GetChannelRequest.Builder
- bitField0_ - Variable in class io.grpc.channelz.v1.GetChannelResponse
- bitField0_ - Variable in class io.grpc.channelz.v1.GetChannelResponse.Builder
- bitField0_ - Variable in class io.grpc.channelz.v1.GetServerRequest.Builder
- bitField0_ - Variable in class io.grpc.channelz.v1.GetServerResponse
- bitField0_ - Variable in class io.grpc.channelz.v1.GetServerResponse.Builder
- bitField0_ - Variable in class io.grpc.channelz.v1.GetServerSocketsRequest.Builder
- bitField0_ - Variable in class io.grpc.channelz.v1.GetServerSocketsResponse.Builder
- bitField0_ - Variable in class io.grpc.channelz.v1.GetServersRequest.Builder
- bitField0_ - Variable in class io.grpc.channelz.v1.GetServersResponse.Builder
- bitField0_ - Variable in class io.grpc.channelz.v1.GetSocketRequest.Builder
- bitField0_ - Variable in class io.grpc.channelz.v1.GetSocketResponse
- bitField0_ - Variable in class io.grpc.channelz.v1.GetSocketResponse.Builder
- bitField0_ - Variable in class io.grpc.channelz.v1.GetSubchannelRequest.Builder
- bitField0_ - Variable in class io.grpc.channelz.v1.GetSubchannelResponse
- bitField0_ - Variable in class io.grpc.channelz.v1.GetSubchannelResponse.Builder
- bitField0_ - Variable in class io.grpc.channelz.v1.GetTopChannelsRequest.Builder
- bitField0_ - Variable in class io.grpc.channelz.v1.GetTopChannelsResponse.Builder
- bitField0_ - Variable in class io.grpc.channelz.v1.Security.Builder
- bitField0_ - Variable in class io.grpc.channelz.v1.Security.OtherSecurity
- bitField0_ - Variable in class io.grpc.channelz.v1.Security.OtherSecurity.Builder
- bitField0_ - Variable in class io.grpc.channelz.v1.Security.Tls.Builder
- bitField0_ - Variable in class io.grpc.channelz.v1.Server
- bitField0_ - Variable in class io.grpc.channelz.v1.Server.Builder
- bitField0_ - Variable in class io.grpc.channelz.v1.ServerData
- bitField0_ - Variable in class io.grpc.channelz.v1.ServerData.Builder
- bitField0_ - Variable in class io.grpc.channelz.v1.ServerRef.Builder
- bitField0_ - Variable in class io.grpc.channelz.v1.Socket
- bitField0_ - Variable in class io.grpc.channelz.v1.Socket.Builder
- bitField0_ - Variable in class io.grpc.channelz.v1.SocketData
- bitField0_ - Variable in class io.grpc.channelz.v1.SocketData.Builder
- bitField0_ - Variable in class io.grpc.channelz.v1.SocketOption
- bitField0_ - Variable in class io.grpc.channelz.v1.SocketOption.Builder
- bitField0_ - Variable in class io.grpc.channelz.v1.SocketOptionLinger
- bitField0_ - Variable in class io.grpc.channelz.v1.SocketOptionLinger.Builder
- bitField0_ - Variable in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
- bitField0_ - Variable in class io.grpc.channelz.v1.SocketOptionTimeout
- bitField0_ - Variable in class io.grpc.channelz.v1.SocketOptionTimeout.Builder
- bitField0_ - Variable in class io.grpc.channelz.v1.SocketRef.Builder
- bitField0_ - Variable in class io.grpc.channelz.v1.Subchannel
- bitField0_ - Variable in class io.grpc.channelz.v1.Subchannel.Builder
- bitField0_ - Variable in class io.grpc.channelz.v1.SubchannelRef.Builder
- bitField0_ - Variable in class io.grpc.health.v1.HealthCheckRequest.Builder
- bitField0_ - Variable in class io.grpc.health.v1.HealthCheckResponse.Builder
- bitField0_ - Variable in class io.grpc.lb.v1.ClientStats
- bitField0_ - Variable in class io.grpc.lb.v1.ClientStats.Builder
- bitField0_ - Variable in class io.grpc.lb.v1.ClientStatsPerToken.Builder
- bitField0_ - Variable in class io.grpc.lb.v1.InitialLoadBalanceRequest.Builder
- bitField0_ - Variable in class io.grpc.lb.v1.InitialLoadBalanceResponse
- bitField0_ - Variable in class io.grpc.lb.v1.InitialLoadBalanceResponse.Builder
- bitField0_ - Variable in class io.grpc.lb.v1.LoadBalanceRequest.Builder
- bitField0_ - Variable in class io.grpc.lb.v1.LoadBalanceResponse.Builder
- bitField0_ - Variable in class io.grpc.lb.v1.Server.Builder
- bitField0_ - Variable in class io.grpc.lb.v1.ServerList.Builder
- bitField0_ - Variable in class io.grpc.lookup.v1.GrpcKeyBuilder
- bitField0_ - Variable in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
- bitField0_ - Variable in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys.Builder
- bitField0_ - Variable in class io.grpc.lookup.v1.GrpcKeyBuilder.Name.Builder
- bitField0_ - Variable in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
- bitField0_ - Variable in class io.grpc.lookup.v1.NameMatcher.Builder
- bitField0_ - Variable in class io.grpc.lookup.v1.RouteLookupClusterSpecifier
- bitField0_ - Variable in class io.grpc.lookup.v1.RouteLookupClusterSpecifier.Builder
- bitField0_ - Variable in class io.grpc.lookup.v1.RouteLookupConfig
- bitField0_ - Variable in class io.grpc.lookup.v1.RouteLookupConfig.Builder
- bitField0_ - Variable in class io.grpc.lookup.v1.RouteLookupRequest.Builder
- bitField0_ - Variable in class io.grpc.lookup.v1.RouteLookupResponse.Builder
- bitField0_ - Variable in class io.grpc.reflection.v1.ErrorResponse.Builder
- bitField0_ - Variable in class io.grpc.reflection.v1.ExtensionNumberResponse.Builder
- bitField0_ - Variable in class io.grpc.reflection.v1.ExtensionRequest.Builder
- bitField0_ - Variable in class io.grpc.reflection.v1.FileDescriptorResponse.Builder
- bitField0_ - Variable in class io.grpc.reflection.v1.ListServiceResponse.Builder
- bitField0_ - Variable in class io.grpc.reflection.v1.ServerReflectionRequest.Builder
- bitField0_ - Variable in class io.grpc.reflection.v1.ServerReflectionResponse
- bitField0_ - Variable in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
- bitField0_ - Variable in class io.grpc.reflection.v1.ServiceResponse.Builder
- bitField0_ - Variable in class io.grpc.reflection.v1alpha.ErrorResponse.Builder
- bitField0_ - Variable in class io.grpc.reflection.v1alpha.ExtensionNumberResponse.Builder
- bitField0_ - Variable in class io.grpc.reflection.v1alpha.ExtensionRequest.Builder
- bitField0_ - Variable in class io.grpc.reflection.v1alpha.FileDescriptorResponse.Builder
- bitField0_ - Variable in class io.grpc.reflection.v1alpha.ListServiceResponse.Builder
- bitField0_ - Variable in class io.grpc.reflection.v1alpha.ServerReflectionRequest.Builder
- bitField0_ - Variable in class io.grpc.reflection.v1alpha.ServerReflectionResponse
- bitField0_ - Variable in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
- bitField0_ - Variable in class io.grpc.reflection.v1alpha.ServiceResponse.Builder
- bitmap - Variable in class io.grpc.PersistentHashArrayMappedTrie.CompressedIndex
- BITS - Static variable in class io.grpc.PersistentHashArrayMappedTrie.CompressedIndex
- BITS_MASK - Static variable in class io.grpc.PersistentHashArrayMappedTrie.CompressedIndex
- bkoffPolProvider - Variable in class io.grpc.internal.PickFirstLeafLoadBalancer
- blacklistedMethods - Variable in class io.grpc.protobuf.services.BinlogHelper.FactoryImpl
- BLOCKING - Enum constant in enum io.grpc.stub.ClientCalls.StubType
- BLOCKING - Enum constant in enum io.grpc.stub.InternalClientCalls.StubType
- BlockingResponseStream(ClientCall<?, T>) - Constructor for class io.grpc.stub.ClientCalls.BlockingResponseStream
- blockingServerStreamingCall(Channel, MethodDescriptor<ReqT, RespT>, CallOptions, ReqT) - Static method in class io.grpc.stub.ClientCalls
-
Executes a server-streaming call returning a blocking
Iterator
over the response stream. - blockingServerStreamingCall(ClientCall<ReqT, RespT>, ReqT) - Static method in class io.grpc.stub.ClientCalls
-
Executes a server-streaming call returning a blocking
Iterator
over the response stream. - blockingUnaryCall(Channel, MethodDescriptor<ReqT, RespT>, CallOptions, ReqT) - Static method in class io.grpc.stub.ClientCalls
-
Executes a unary call and blocks on the response.
- blockingUnaryCall(ClientCall<ReqT, RespT>, ReqT) - Static method in class io.grpc.stub.ClientCalls
-
Executes a unary call and blocks on the response.
- BODY - Enum constant in enum io.grpc.internal.MessageDeframer.State
- bossEventLoopGroup(EventLoopGroup) - Method in class io.grpc.netty.NettyServerBuilder
-
Provides the boss EventGroupLoop to the server.
- bossEventLoopGroupPool - Variable in class io.grpc.netty.NettyServerBuilder
- bossEventLoopGroupPool(ObjectPool<? extends EventLoopGroup>) - Method in class io.grpc.netty.NettyServerBuilder
- bossExecutor - Variable in class io.grpc.netty.NettyServer
- bossGroup - Variable in class io.grpc.netty.NettyServer
- bossGroupPool - Variable in class io.grpc.netty.NettyServer
- bucketBoundaries - Variable in class io.grpc.DoubleHistogramMetricInstrument
- bucketBoundaries - Variable in class io.grpc.LongHistogramMetricInstrument
- buf - Variable in class io.grpc.internal.ForwardingReadableBuffer
- BUF_SIZE - Static variable in class io.grpc.protobuf.lite.ProtoLiteUtils
- buffer - Variable in class io.grpc.internal.InsightBuilder
- buffer - Variable in class io.grpc.internal.MessageFramer
- buffer - Variable in class io.grpc.internal.ReadableBuffers.BufferInputStream
- buffer - Variable in class io.grpc.internal.RetriableStream.State
-
A list of buffered ClientStream runnables.
- buffer - Variable in class io.grpc.netty.NettyReadableBuffer
- buffer - Variable in class io.grpc.servlet.jakarta.ServletAdapter.GrpcReadListener
- buffer - Variable in class io.grpc.servlet.ServletAdapter.GrpcReadListener
- buffer - Variable in class io.grpc.stub.ClientCalls.BlockingResponseStream
- buffer() - Method in class io.grpc.netty.NettyReadableBuffer
- BUFFER_ENTRY - Static variable in class io.grpc.grpclb.GrpclbState
- BUFFER_PICKER - Static variable in class io.grpc.util.GracefulSwitchLoadBalancer
- bufferAllocator - Variable in class io.grpc.internal.MessageFramer
- BufferChainOutputStream() - Constructor for class io.grpc.internal.MessageFramer.BufferChainOutputStream
- bufferedWrites - Variable in class io.grpc.netty.WriteBufferingAndExceptionHandler
- BufferInputStream(ReadableBuffer) - Constructor for class io.grpc.internal.ReadableBuffers.BufferInputStream
- bufferLimitExceeded - Variable in class io.grpc.internal.RetriableStream.Substream
- bufferList - Variable in class io.grpc.internal.MessageFramer.BufferChainOutputStream
- bufferNeeded - Variable in class io.grpc.internal.RetriableStream.BufferSizeTracer
- buffers - Variable in class io.grpc.internal.CompositeReadableBuffer
- BufferSizeTracer(RetriableStream.Substream) - Constructor for class io.grpc.internal.RetriableStream.BufferSizeTracer
- bufferUsed - Variable in class io.grpc.internal.RetriableStream.ChannelBufferMeter
- bufs - Static variable in class io.grpc.protobuf.lite.ProtoLiteUtils.MessageMarshaller
- build() - Method in class io.grpc.Attributes.Builder
-
Build the attributes.
- build() - Method in class io.grpc.binarylog.v1.Address.Builder
- build() - Method in class io.grpc.binarylog.v1.ClientHeader.Builder
- build() - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
- build() - Method in class io.grpc.binarylog.v1.Message.Builder
- build() - Method in class io.grpc.binarylog.v1.Metadata.Builder
- build() - Method in class io.grpc.binarylog.v1.MetadataEntry.Builder
- build() - Method in class io.grpc.binarylog.v1.ServerHeader.Builder
- build() - Method in class io.grpc.binarylog.v1.Trailer.Builder
- build() - Method in class io.grpc.CallOptions.Builder
- build() - Method in class io.grpc.channelz.v1.Address.Builder
- build() - Method in class io.grpc.channelz.v1.Address.OtherAddress.Builder
- build() - Method in class io.grpc.channelz.v1.Address.TcpIpAddress.Builder
- build() - Method in class io.grpc.channelz.v1.Address.UdsAddress.Builder
- build() - Method in class io.grpc.channelz.v1.Channel.Builder
- build() - Method in class io.grpc.channelz.v1.ChannelConnectivityState.Builder
- build() - Method in class io.grpc.channelz.v1.ChannelData.Builder
- build() - Method in class io.grpc.channelz.v1.ChannelRef.Builder
- build() - Method in class io.grpc.channelz.v1.ChannelTrace.Builder
- build() - Method in class io.grpc.channelz.v1.ChannelTraceEvent.Builder
- build() - Method in class io.grpc.channelz.v1.GetChannelRequest.Builder
- build() - Method in class io.grpc.channelz.v1.GetChannelResponse.Builder
- build() - Method in class io.grpc.channelz.v1.GetServerRequest.Builder
- build() - Method in class io.grpc.channelz.v1.GetServerResponse.Builder
- build() - Method in class io.grpc.channelz.v1.GetServerSocketsRequest.Builder
- build() - Method in class io.grpc.channelz.v1.GetServerSocketsResponse.Builder
- build() - Method in class io.grpc.channelz.v1.GetServersRequest.Builder
- build() - Method in class io.grpc.channelz.v1.GetServersResponse.Builder
- build() - Method in class io.grpc.channelz.v1.GetSocketRequest.Builder
- build() - Method in class io.grpc.channelz.v1.GetSocketResponse.Builder
- build() - Method in class io.grpc.channelz.v1.GetSubchannelRequest.Builder
- build() - Method in class io.grpc.channelz.v1.GetSubchannelResponse.Builder
- build() - Method in class io.grpc.channelz.v1.GetTopChannelsRequest.Builder
- build() - Method in class io.grpc.channelz.v1.GetTopChannelsResponse.Builder
- build() - Method in class io.grpc.channelz.v1.Security.Builder
- build() - Method in class io.grpc.channelz.v1.Security.OtherSecurity.Builder
- build() - Method in class io.grpc.channelz.v1.Security.Tls.Builder
- build() - Method in class io.grpc.channelz.v1.Server.Builder
- build() - Method in class io.grpc.channelz.v1.ServerData.Builder
- build() - Method in class io.grpc.channelz.v1.ServerRef.Builder
- build() - Method in class io.grpc.channelz.v1.Socket.Builder
- build() - Method in class io.grpc.channelz.v1.SocketData.Builder
- build() - Method in class io.grpc.channelz.v1.SocketOption.Builder
- build() - Method in class io.grpc.channelz.v1.SocketOptionLinger.Builder
- build() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
- build() - Method in class io.grpc.channelz.v1.SocketOptionTimeout.Builder
- build() - Method in class io.grpc.channelz.v1.SocketRef.Builder
- build() - Method in class io.grpc.channelz.v1.Subchannel.Builder
- build() - Method in class io.grpc.channelz.v1.SubchannelRef.Builder
- build() - Method in class io.grpc.ClientStreamTracer.StreamInfo.Builder
-
Builds a new StreamInfo.
- build() - Method in class io.grpc.ForwardingChannelBuilder2
-
Returns the
ManagedChannel
built by the delegate by default. - build() - Method in class io.grpc.ForwardingServerBuilder
-
Returns the
Server
built by the delegate by default. - build() - Method in class io.grpc.health.v1.HealthCheckRequest.Builder
- build() - Method in class io.grpc.health.v1.HealthCheckResponse.Builder
- build() - Method in class io.grpc.HttpConnectProxiedSocketAddress.Builder
-
Creates an
HttpConnectProxiedSocketAddress
. - build() - Method in class io.grpc.internal.InternalHandlerRegistry.Builder
- build() - Method in class io.grpc.internal.ManagedChannelImplBuilder
- build() - Method in class io.grpc.internal.ServerImplBuilder
- build() - Method in class io.grpc.InternalChannelz.ChannelStats.Builder
-
Builds an instance.
- build() - Method in class io.grpc.InternalChannelz.ChannelTrace.Builder
-
Builds a new ChannelTrace instance.
- build() - Method in class io.grpc.InternalChannelz.ChannelTrace.Event.Builder
-
Builds a new Event instance.
- build() - Method in class io.grpc.InternalChannelz.ServerStats.Builder
-
Builds an instance.
- build() - Method in class io.grpc.InternalChannelz.SocketOptions.Builder
- build() - Method in class io.grpc.InternalChannelz.TcpInfo.Builder
-
Builds an instance.
- build() - Method in class io.grpc.InternalConfigSelector.Result.Builder
-
Build this
InternalConfigSelector.Result
. - build() - Method in class io.grpc.lb.v1.ClientStats.Builder
- build() - Method in class io.grpc.lb.v1.ClientStatsPerToken.Builder
- build() - Method in class io.grpc.lb.v1.FallbackResponse.Builder
- build() - Method in class io.grpc.lb.v1.InitialLoadBalanceRequest.Builder
- build() - Method in class io.grpc.lb.v1.InitialLoadBalanceResponse.Builder
- build() - Method in class io.grpc.lb.v1.LoadBalanceRequest.Builder
- build() - Method in class io.grpc.lb.v1.LoadBalanceResponse.Builder
- build() - Method in class io.grpc.lb.v1.Server.Builder
- build() - Method in class io.grpc.lb.v1.ServerList.Builder
- build() - Method in class io.grpc.LoadBalancer.CreateSubchannelArgs.Builder
-
Creates a new args object.
- build() - Method in class io.grpc.LoadBalancer.ResolvedAddresses.Builder
-
Constructs the
LoadBalancer.ResolvedAddresses
. - build() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
- build() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys.Builder
- build() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Name.Builder
- build() - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
- build() - Method in class io.grpc.lookup.v1.NameMatcher.Builder
- build() - Method in class io.grpc.lookup.v1.RouteLookupClusterSpecifier.Builder
- build() - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
- build() - Method in class io.grpc.lookup.v1.RouteLookupRequest.Builder
- build() - Method in class io.grpc.lookup.v1.RouteLookupResponse.Builder
- build() - Method in class io.grpc.ManagedChannelBuilder
-
Builds a channel using the given parameters.
- build() - Method in class io.grpc.MethodDescriptor.Builder
-
Builds the method descriptor.
- build() - Method in class io.grpc.NameResolver.Args.Builder
-
Builds an
NameResolver.Args
. - build() - Method in class io.grpc.NameResolver.ResolutionResult.Builder
-
Constructs a new
NameResolver.ResolutionResult
from this builder. - build() - Method in class io.grpc.reflection.v1.ErrorResponse.Builder
- build() - Method in class io.grpc.reflection.v1.ExtensionNumberResponse.Builder
- build() - Method in class io.grpc.reflection.v1.ExtensionRequest.Builder
- build() - Method in class io.grpc.reflection.v1.FileDescriptorResponse.Builder
- build() - Method in class io.grpc.reflection.v1.ListServiceResponse.Builder
- build() - Method in class io.grpc.reflection.v1.ServerReflectionRequest.Builder
- build() - Method in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
- build() - Method in class io.grpc.reflection.v1.ServiceResponse.Builder
- build() - Method in class io.grpc.reflection.v1alpha.ErrorResponse.Builder
- build() - Method in class io.grpc.reflection.v1alpha.ExtensionNumberResponse.Builder
- build() - Method in class io.grpc.reflection.v1alpha.ExtensionRequest.Builder
- build() - Method in class io.grpc.reflection.v1alpha.FileDescriptorResponse.Builder
- build() - Method in class io.grpc.reflection.v1alpha.ListServiceResponse.Builder
- build() - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest.Builder
- build() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
- build() - Method in class io.grpc.reflection.v1alpha.ServiceResponse.Builder
- build() - Method in class io.grpc.rls.AdaptiveThrottler.Builder
- build() - Method in class io.grpc.rls.AutoValue_RlsProtoData_RouteLookupConfig.Builder
- build() - Method in class io.grpc.rls.CachingRlsLbClient.Builder
- build() - Method in class io.grpc.rls.RlsProtoData.RouteLookupConfig.Builder
- build() - Method in class io.grpc.ServerBuilder
-
Builds a server using the given parameters.
- build() - Method in class io.grpc.ServerServiceDefinition.Builder
-
Construct new ServerServiceDefinition.
- build() - Method in class io.grpc.ServiceDescriptor.Builder
-
Constructs a new
ServiceDescriptor
. - build() - Method in class io.grpc.servlet.jakarta.ServletServerBuilder
-
Builds a gRPC server that can run as a servlet.
- build() - Method in class io.grpc.servlet.ServletServerBuilder
-
Builds a gRPC server that can run as a servlet.
- build() - Method in class io.grpc.TlsChannelCredentials.Builder
-
Construct the credentials.
- build() - Method in class io.grpc.TlsServerCredentials.Builder
-
Construct the credentials.
- build() - Method in class io.grpc.util.AdvancedTlsX509TrustManager.Builder
- build() - Method in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig.Builder
-
Builds a new instance of
OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig
. - build() - Method in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig.FailurePercentageEjection.Builder
-
Builds a new instance of
OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig.FailurePercentageEjection
. - build() - Method in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig.SuccessRateEjection.Builder
-
Builds a new instance of
OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig.SuccessRateEjection
. - build(Channel, CallOptions) - Method in class io.grpc.channelz.v1.ChannelzGrpc.ChannelzBlockingStub
- build(Channel, CallOptions) - Method in class io.grpc.channelz.v1.ChannelzGrpc.ChannelzFutureStub
- build(Channel, CallOptions) - Method in class io.grpc.channelz.v1.ChannelzGrpc.ChannelzStub
- build(Channel, CallOptions) - Method in class io.grpc.health.v1.HealthGrpc.HealthBlockingStub
- build(Channel, CallOptions) - Method in class io.grpc.health.v1.HealthGrpc.HealthFutureStub
- build(Channel, CallOptions) - Method in class io.grpc.health.v1.HealthGrpc.HealthStub
- build(Channel, CallOptions) - Method in class io.grpc.lb.v1.LoadBalancerGrpc.LoadBalancerBlockingStub
- build(Channel, CallOptions) - Method in class io.grpc.lb.v1.LoadBalancerGrpc.LoadBalancerFutureStub
- build(Channel, CallOptions) - Method in class io.grpc.lb.v1.LoadBalancerGrpc.LoadBalancerStub
- build(Channel, CallOptions) - Method in class io.grpc.lookup.v1.RouteLookupServiceGrpc.RouteLookupServiceBlockingStub
- build(Channel, CallOptions) - Method in class io.grpc.lookup.v1.RouteLookupServiceGrpc.RouteLookupServiceFutureStub
- build(Channel, CallOptions) - Method in class io.grpc.lookup.v1.RouteLookupServiceGrpc.RouteLookupServiceStub
- build(Channel, CallOptions) - Method in class io.grpc.reflection.v1.ServerReflectionGrpc.ServerReflectionBlockingStub
- build(Channel, CallOptions) - Method in class io.grpc.reflection.v1.ServerReflectionGrpc.ServerReflectionFutureStub
- build(Channel, CallOptions) - Method in class io.grpc.reflection.v1.ServerReflectionGrpc.ServerReflectionStub
- build(Channel, CallOptions) - Method in class io.grpc.reflection.v1alpha.ServerReflectionGrpc.ServerReflectionBlockingStub
- build(Channel, CallOptions) - Method in class io.grpc.reflection.v1alpha.ServerReflectionGrpc.ServerReflectionFutureStub
- build(Channel, CallOptions) - Method in class io.grpc.reflection.v1alpha.ServerReflectionGrpc.ServerReflectionStub
- build(Channel, CallOptions) - Method in class io.grpc.stub.AbstractStub
-
Returns a new stub with the given channel for the provided method configurations.
- buildAndStart() - Method in class io.grpc.servlet.jakarta.ServletServerBuilder
- buildAndStart() - Method in class io.grpc.servlet.ServletServerBuilder
- buildClientTransportFactory() - Method in interface io.grpc.internal.ManagedChannelImplBuilder.ClientTransportFactoryBuilder
- buildClientTransportFactory() - Method in class io.grpc.internal.ManagedChannelImplBuilder.UnsupportedClientTransportFactoryBuilder
- buildClientTransportFactory() - Method in class io.grpc.netty.NettyChannelBuilder.NettyChannelTransportFactoryBuilder
- buildClientTransportServers(List<? extends ServerStreamTracer.Factory>) - Method in interface io.grpc.internal.ServerImplBuilder.ClientTransportServersBuilder
- buildClientTransportServers(List<? extends ServerStreamTracer.Factory>) - Method in class io.grpc.netty.NettyServerBuilder.NettyClientTransportServersBuilder
- builder() - Static method in class io.grpc.rls.AdaptiveThrottler
- builder() - Static method in class io.grpc.rls.RlsProtoData.RouteLookupConfig
- builder(ServiceDescriptor) - Static method in class io.grpc.ServerServiceDefinition
- builder(String) - Static method in class io.grpc.ServerServiceDefinition
-
Convenience that constructs a
ServiceDescriptor
simultaneously. - Builder() - Constructor for class io.grpc.binarylog.v1.Address.Builder
- Builder() - Constructor for class io.grpc.binarylog.v1.ClientHeader.Builder
- Builder() - Constructor for class io.grpc.binarylog.v1.GrpcLogEntry.Builder
- Builder() - Constructor for class io.grpc.binarylog.v1.Message.Builder
- Builder() - Constructor for class io.grpc.binarylog.v1.Metadata.Builder
- Builder() - Constructor for class io.grpc.binarylog.v1.MetadataEntry.Builder
- Builder() - Constructor for class io.grpc.binarylog.v1.ServerHeader.Builder
- Builder() - Constructor for class io.grpc.binarylog.v1.Trailer.Builder
- Builder() - Constructor for class io.grpc.CallOptions.Builder
- Builder() - Constructor for class io.grpc.channelz.v1.Address.Builder
- Builder() - Constructor for class io.grpc.channelz.v1.Address.OtherAddress.Builder
- Builder() - Constructor for class io.grpc.channelz.v1.Address.TcpIpAddress.Builder
- Builder() - Constructor for class io.grpc.channelz.v1.Address.UdsAddress.Builder
- Builder() - Constructor for class io.grpc.channelz.v1.Channel.Builder
- Builder() - Constructor for class io.grpc.channelz.v1.ChannelConnectivityState.Builder
- Builder() - Constructor for class io.grpc.channelz.v1.ChannelData.Builder
- Builder() - Constructor for class io.grpc.channelz.v1.ChannelRef.Builder
- Builder() - Constructor for class io.grpc.channelz.v1.ChannelTrace.Builder
- Builder() - Constructor for class io.grpc.channelz.v1.ChannelTraceEvent.Builder
- Builder() - Constructor for class io.grpc.channelz.v1.GetChannelRequest.Builder
- Builder() - Constructor for class io.grpc.channelz.v1.GetChannelResponse.Builder
- Builder() - Constructor for class io.grpc.channelz.v1.GetServerRequest.Builder
- Builder() - Constructor for class io.grpc.channelz.v1.GetServerResponse.Builder
- Builder() - Constructor for class io.grpc.channelz.v1.GetServerSocketsRequest.Builder
- Builder() - Constructor for class io.grpc.channelz.v1.GetServerSocketsResponse.Builder
- Builder() - Constructor for class io.grpc.channelz.v1.GetServersRequest.Builder
- Builder() - Constructor for class io.grpc.channelz.v1.GetServersResponse.Builder
- Builder() - Constructor for class io.grpc.channelz.v1.GetSocketRequest.Builder
- Builder() - Constructor for class io.grpc.channelz.v1.GetSocketResponse.Builder
- Builder() - Constructor for class io.grpc.channelz.v1.GetSubchannelRequest.Builder
- Builder() - Constructor for class io.grpc.channelz.v1.GetSubchannelResponse.Builder
- Builder() - Constructor for class io.grpc.channelz.v1.GetTopChannelsRequest.Builder
- Builder() - Constructor for class io.grpc.channelz.v1.GetTopChannelsResponse.Builder
- Builder() - Constructor for class io.grpc.channelz.v1.Security.Builder
- Builder() - Constructor for class io.grpc.channelz.v1.Security.OtherSecurity.Builder
- Builder() - Constructor for class io.grpc.channelz.v1.Security.Tls.Builder
- Builder() - Constructor for class io.grpc.channelz.v1.Server.Builder
- Builder() - Constructor for class io.grpc.channelz.v1.ServerData.Builder
- Builder() - Constructor for class io.grpc.channelz.v1.ServerRef.Builder
- Builder() - Constructor for class io.grpc.channelz.v1.Socket.Builder
- Builder() - Constructor for class io.grpc.channelz.v1.SocketData.Builder
- Builder() - Constructor for class io.grpc.channelz.v1.SocketOption.Builder
- Builder() - Constructor for class io.grpc.channelz.v1.SocketOptionLinger.Builder
- Builder() - Constructor for class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
- Builder() - Constructor for class io.grpc.channelz.v1.SocketOptionTimeout.Builder
- Builder() - Constructor for class io.grpc.channelz.v1.SocketRef.Builder
- Builder() - Constructor for class io.grpc.channelz.v1.Subchannel.Builder
- Builder() - Constructor for class io.grpc.channelz.v1.SubchannelRef.Builder
- Builder() - Constructor for class io.grpc.ClientStreamTracer.StreamInfo.Builder
- Builder() - Constructor for class io.grpc.health.v1.HealthCheckRequest.Builder
- Builder() - Constructor for class io.grpc.health.v1.HealthCheckResponse.Builder
- Builder() - Constructor for class io.grpc.HttpConnectProxiedSocketAddress.Builder
- Builder() - Constructor for class io.grpc.internal.InternalHandlerRegistry.Builder
- Builder() - Constructor for class io.grpc.InternalChannelz.ChannelStats.Builder
- Builder() - Constructor for class io.grpc.InternalChannelz.ChannelTrace.Builder
- Builder() - Constructor for class io.grpc.InternalChannelz.ChannelTrace.Event.Builder
- Builder() - Constructor for class io.grpc.InternalChannelz.ServerStats.Builder
- Builder() - Constructor for class io.grpc.InternalChannelz.SocketOptions.Builder
- Builder() - Constructor for class io.grpc.InternalChannelz.TcpInfo.Builder
- Builder() - Constructor for class io.grpc.InternalConfigSelector.Result.Builder
- Builder() - Constructor for class io.grpc.lb.v1.ClientStats.Builder
- Builder() - Constructor for class io.grpc.lb.v1.ClientStatsPerToken.Builder
- Builder() - Constructor for class io.grpc.lb.v1.FallbackResponse.Builder
- Builder() - Constructor for class io.grpc.lb.v1.InitialLoadBalanceRequest.Builder
- Builder() - Constructor for class io.grpc.lb.v1.InitialLoadBalanceResponse.Builder
- Builder() - Constructor for class io.grpc.lb.v1.LoadBalanceRequest.Builder
- Builder() - Constructor for class io.grpc.lb.v1.LoadBalanceResponse.Builder
- Builder() - Constructor for class io.grpc.lb.v1.Server.Builder
- Builder() - Constructor for class io.grpc.lb.v1.ServerList.Builder
- Builder() - Constructor for class io.grpc.LoadBalancer.CreateSubchannelArgs.Builder
- Builder() - Constructor for class io.grpc.LoadBalancer.ResolvedAddresses.Builder
- Builder() - Constructor for class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
- Builder() - Constructor for class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys.Builder
- Builder() - Constructor for class io.grpc.lookup.v1.GrpcKeyBuilder.Name.Builder
- Builder() - Constructor for class io.grpc.lookup.v1.HttpKeyBuilder.Builder
- Builder() - Constructor for class io.grpc.lookup.v1.NameMatcher.Builder
- Builder() - Constructor for class io.grpc.lookup.v1.RouteLookupClusterSpecifier.Builder
- Builder() - Constructor for class io.grpc.lookup.v1.RouteLookupConfig.Builder
- Builder() - Constructor for class io.grpc.lookup.v1.RouteLookupRequest.Builder
- Builder() - Constructor for class io.grpc.lookup.v1.RouteLookupResponse.Builder
- Builder() - Constructor for class io.grpc.MethodDescriptor.Builder
- Builder() - Constructor for class io.grpc.NameResolver.Args.Builder
- Builder() - Constructor for class io.grpc.NameResolver.ResolutionResult.Builder
- Builder() - Constructor for class io.grpc.reflection.v1.ErrorResponse.Builder
- Builder() - Constructor for class io.grpc.reflection.v1.ExtensionNumberResponse.Builder
- Builder() - Constructor for class io.grpc.reflection.v1.ExtensionRequest.Builder
- Builder() - Constructor for class io.grpc.reflection.v1.FileDescriptorResponse.Builder
- Builder() - Constructor for class io.grpc.reflection.v1.ListServiceResponse.Builder
- Builder() - Constructor for class io.grpc.reflection.v1.ServerReflectionRequest.Builder
- Builder() - Constructor for class io.grpc.reflection.v1.ServerReflectionResponse.Builder
- Builder() - Constructor for class io.grpc.reflection.v1.ServiceResponse.Builder
- Builder() - Constructor for class io.grpc.reflection.v1alpha.ErrorResponse.Builder
- Builder() - Constructor for class io.grpc.reflection.v1alpha.ExtensionNumberResponse.Builder
- Builder() - Constructor for class io.grpc.reflection.v1alpha.ExtensionRequest.Builder
- Builder() - Constructor for class io.grpc.reflection.v1alpha.FileDescriptorResponse.Builder
- Builder() - Constructor for class io.grpc.reflection.v1alpha.ListServiceResponse.Builder
- Builder() - Constructor for class io.grpc.reflection.v1alpha.ServerReflectionRequest.Builder
- Builder() - Constructor for class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
- Builder() - Constructor for class io.grpc.reflection.v1alpha.ServiceResponse.Builder
- Builder() - Constructor for class io.grpc.rls.AdaptiveThrottler.Builder
- Builder() - Constructor for class io.grpc.rls.AutoValue_RlsProtoData_RouteLookupConfig.Builder
- Builder() - Constructor for class io.grpc.rls.CachingRlsLbClient.Builder
- Builder() - Constructor for class io.grpc.rls.RlsProtoData.RouteLookupConfig.Builder
- Builder() - Constructor for class io.grpc.TlsChannelCredentials.Builder
- Builder() - Constructor for class io.grpc.TlsServerCredentials.Builder
- Builder() - Constructor for class io.grpc.util.AdvancedTlsX509TrustManager.Builder
- Builder() - Constructor for class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig.Builder
- Builder() - Constructor for class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig.FailurePercentageEjection.Builder
- Builder() - Constructor for class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig.SuccessRateEjection.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.binarylog.v1.Address.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.binarylog.v1.ClientHeader.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.binarylog.v1.GrpcLogEntry.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.binarylog.v1.Message.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.binarylog.v1.Metadata.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.binarylog.v1.MetadataEntry.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.binarylog.v1.ServerHeader.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.binarylog.v1.Trailer.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.channelz.v1.Address.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.channelz.v1.Address.OtherAddress.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.channelz.v1.Address.TcpIpAddress.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.channelz.v1.Address.UdsAddress.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.channelz.v1.Channel.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.channelz.v1.ChannelConnectivityState.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.channelz.v1.ChannelData.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.channelz.v1.ChannelRef.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.channelz.v1.ChannelTrace.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.channelz.v1.ChannelTraceEvent.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.channelz.v1.GetChannelRequest.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.channelz.v1.GetChannelResponse.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.channelz.v1.GetServerRequest.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.channelz.v1.GetServerResponse.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.channelz.v1.GetServerSocketsRequest.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.channelz.v1.GetServerSocketsResponse.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.channelz.v1.GetServersRequest.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.channelz.v1.GetServersResponse.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.channelz.v1.GetSocketRequest.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.channelz.v1.GetSocketResponse.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.channelz.v1.GetSubchannelRequest.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.channelz.v1.GetSubchannelResponse.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.channelz.v1.GetTopChannelsRequest.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.channelz.v1.GetTopChannelsResponse.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.channelz.v1.Security.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.channelz.v1.Security.OtherSecurity.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.channelz.v1.Security.Tls.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.channelz.v1.Server.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.channelz.v1.ServerData.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.channelz.v1.ServerRef.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.channelz.v1.Socket.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.channelz.v1.SocketData.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.channelz.v1.SocketOption.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.channelz.v1.SocketOptionLinger.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.channelz.v1.SocketOptionTimeout.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.channelz.v1.SocketRef.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.channelz.v1.Subchannel.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.channelz.v1.SubchannelRef.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.health.v1.HealthCheckRequest.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.health.v1.HealthCheckResponse.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.lb.v1.ClientStats.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.lb.v1.ClientStatsPerToken.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.lb.v1.FallbackResponse.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.lb.v1.InitialLoadBalanceRequest.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.lb.v1.InitialLoadBalanceResponse.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.lb.v1.LoadBalanceRequest.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.lb.v1.LoadBalanceResponse.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.lb.v1.Server.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.lb.v1.ServerList.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.lookup.v1.GrpcKeyBuilder.Name.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.lookup.v1.HttpKeyBuilder.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.lookup.v1.NameMatcher.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.lookup.v1.RouteLookupClusterSpecifier.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.lookup.v1.RouteLookupConfig.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.lookup.v1.RouteLookupRequest.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.lookup.v1.RouteLookupResponse.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.reflection.v1.ErrorResponse.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.reflection.v1.ExtensionNumberResponse.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.reflection.v1.ExtensionRequest.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.reflection.v1.FileDescriptorResponse.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.reflection.v1.ListServiceResponse.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.reflection.v1.ServerReflectionRequest.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.reflection.v1.ServerReflectionResponse.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.reflection.v1.ServiceResponse.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.reflection.v1alpha.ErrorResponse.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.reflection.v1alpha.ExtensionNumberResponse.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.reflection.v1alpha.ExtensionRequest.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.reflection.v1alpha.FileDescriptorResponse.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.reflection.v1alpha.ListServiceResponse.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.reflection.v1alpha.ServerReflectionRequest.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
- Builder(AbstractMessage.BuilderParent) - Constructor for class io.grpc.reflection.v1alpha.ServiceResponse.Builder
- Builder(Attributes) - Constructor for class io.grpc.Attributes.Builder
- Builder(ServiceDescriptor) - Constructor for class io.grpc.ServerServiceDefinition.Builder
- Builder(String) - Constructor for class io.grpc.ServerServiceDefinition.Builder
- Builder(String) - Constructor for class io.grpc.ServiceDescriptor.Builder
- builderForAddress(ManagedChannelProvider, String, int) - Static method in class io.grpc.InternalManagedChannelProvider
- builderForAddress(String, int) - Method in class io.grpc.ManagedChannelProvider
-
Creates a new builder with the given host and port.
- builderForAddress(String, int) - Method in class io.grpc.netty.NettyChannelProvider
- builderForAddress(String, int) - Method in class io.grpc.netty.UdsNettyChannelProvider
- builderForPort(int) - Method in class io.grpc.netty.NettyServerProvider
- builderForPort(int) - Method in class io.grpc.ServerProvider
-
Creates a new builder with the given port.
- builderForPort(ServerProvider, int) - Static method in class io.grpc.InternalServerProvider
- builderForTarget(ManagedChannelProvider, String) - Static method in class io.grpc.InternalManagedChannelProvider
- builderForTarget(String) - Method in class io.grpc.ManagedChannelProvider
-
Creates a new builder with the given target URI.
- builderForTarget(String) - Method in class io.grpc.netty.NettyChannelProvider
- builderForTarget(String) - Method in class io.grpc.netty.UdsNettyChannelProvider
- buildHttp2CodeMap() - Static method in enum io.grpc.internal.GrpcUtil.Http2Error
- buildPartial() - Method in class io.grpc.binarylog.v1.Address.Builder
- buildPartial() - Method in class io.grpc.binarylog.v1.ClientHeader.Builder
- buildPartial() - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
- buildPartial() - Method in class io.grpc.binarylog.v1.Message.Builder
- buildPartial() - Method in class io.grpc.binarylog.v1.Metadata.Builder
- buildPartial() - Method in class io.grpc.binarylog.v1.MetadataEntry.Builder
- buildPartial() - Method in class io.grpc.binarylog.v1.ServerHeader.Builder
- buildPartial() - Method in class io.grpc.binarylog.v1.Trailer.Builder
- buildPartial() - Method in class io.grpc.channelz.v1.Address.Builder
- buildPartial() - Method in class io.grpc.channelz.v1.Address.OtherAddress.Builder
- buildPartial() - Method in class io.grpc.channelz.v1.Address.TcpIpAddress.Builder
- buildPartial() - Method in class io.grpc.channelz.v1.Address.UdsAddress.Builder
- buildPartial() - Method in class io.grpc.channelz.v1.Channel.Builder
- buildPartial() - Method in class io.grpc.channelz.v1.ChannelConnectivityState.Builder
- buildPartial() - Method in class io.grpc.channelz.v1.ChannelData.Builder
- buildPartial() - Method in class io.grpc.channelz.v1.ChannelRef.Builder
- buildPartial() - Method in class io.grpc.channelz.v1.ChannelTrace.Builder
- buildPartial() - Method in class io.grpc.channelz.v1.ChannelTraceEvent.Builder
- buildPartial() - Method in class io.grpc.channelz.v1.GetChannelRequest.Builder
- buildPartial() - Method in class io.grpc.channelz.v1.GetChannelResponse.Builder
- buildPartial() - Method in class io.grpc.channelz.v1.GetServerRequest.Builder
- buildPartial() - Method in class io.grpc.channelz.v1.GetServerResponse.Builder
- buildPartial() - Method in class io.grpc.channelz.v1.GetServerSocketsRequest.Builder
- buildPartial() - Method in class io.grpc.channelz.v1.GetServerSocketsResponse.Builder
- buildPartial() - Method in class io.grpc.channelz.v1.GetServersRequest.Builder
- buildPartial() - Method in class io.grpc.channelz.v1.GetServersResponse.Builder
- buildPartial() - Method in class io.grpc.channelz.v1.GetSocketRequest.Builder
- buildPartial() - Method in class io.grpc.channelz.v1.GetSocketResponse.Builder
- buildPartial() - Method in class io.grpc.channelz.v1.GetSubchannelRequest.Builder
- buildPartial() - Method in class io.grpc.channelz.v1.GetSubchannelResponse.Builder
- buildPartial() - Method in class io.grpc.channelz.v1.GetTopChannelsRequest.Builder
- buildPartial() - Method in class io.grpc.channelz.v1.GetTopChannelsResponse.Builder
- buildPartial() - Method in class io.grpc.channelz.v1.Security.Builder
- buildPartial() - Method in class io.grpc.channelz.v1.Security.OtherSecurity.Builder
- buildPartial() - Method in class io.grpc.channelz.v1.Security.Tls.Builder
- buildPartial() - Method in class io.grpc.channelz.v1.Server.Builder
- buildPartial() - Method in class io.grpc.channelz.v1.ServerData.Builder
- buildPartial() - Method in class io.grpc.channelz.v1.ServerRef.Builder
- buildPartial() - Method in class io.grpc.channelz.v1.Socket.Builder
- buildPartial() - Method in class io.grpc.channelz.v1.SocketData.Builder
- buildPartial() - Method in class io.grpc.channelz.v1.SocketOption.Builder
- buildPartial() - Method in class io.grpc.channelz.v1.SocketOptionLinger.Builder
- buildPartial() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
- buildPartial() - Method in class io.grpc.channelz.v1.SocketOptionTimeout.Builder
- buildPartial() - Method in class io.grpc.channelz.v1.SocketRef.Builder
- buildPartial() - Method in class io.grpc.channelz.v1.Subchannel.Builder
- buildPartial() - Method in class io.grpc.channelz.v1.SubchannelRef.Builder
- buildPartial() - Method in class io.grpc.health.v1.HealthCheckRequest.Builder
- buildPartial() - Method in class io.grpc.health.v1.HealthCheckResponse.Builder
- buildPartial() - Method in class io.grpc.lb.v1.ClientStats.Builder
- buildPartial() - Method in class io.grpc.lb.v1.ClientStatsPerToken.Builder
- buildPartial() - Method in class io.grpc.lb.v1.FallbackResponse.Builder
- buildPartial() - Method in class io.grpc.lb.v1.InitialLoadBalanceRequest.Builder
- buildPartial() - Method in class io.grpc.lb.v1.InitialLoadBalanceResponse.Builder
- buildPartial() - Method in class io.grpc.lb.v1.LoadBalanceRequest.Builder
- buildPartial() - Method in class io.grpc.lb.v1.LoadBalanceResponse.Builder
- buildPartial() - Method in class io.grpc.lb.v1.Server.Builder
- buildPartial() - Method in class io.grpc.lb.v1.ServerList.Builder
- buildPartial() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
- buildPartial() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys.Builder
- buildPartial() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Name.Builder
- buildPartial() - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
- buildPartial() - Method in class io.grpc.lookup.v1.NameMatcher.Builder
- buildPartial() - Method in class io.grpc.lookup.v1.RouteLookupClusterSpecifier.Builder
- buildPartial() - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
- buildPartial() - Method in class io.grpc.lookup.v1.RouteLookupRequest.Builder
- buildPartial() - Method in class io.grpc.lookup.v1.RouteLookupResponse.Builder
- buildPartial() - Method in class io.grpc.reflection.v1.ErrorResponse.Builder
- buildPartial() - Method in class io.grpc.reflection.v1.ExtensionNumberResponse.Builder
- buildPartial() - Method in class io.grpc.reflection.v1.ExtensionRequest.Builder
- buildPartial() - Method in class io.grpc.reflection.v1.FileDescriptorResponse.Builder
- buildPartial() - Method in class io.grpc.reflection.v1.ListServiceResponse.Builder
- buildPartial() - Method in class io.grpc.reflection.v1.ServerReflectionRequest.Builder
- buildPartial() - Method in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
- buildPartial() - Method in class io.grpc.reflection.v1.ServiceResponse.Builder
- buildPartial() - Method in class io.grpc.reflection.v1alpha.ErrorResponse.Builder
- buildPartial() - Method in class io.grpc.reflection.v1alpha.ExtensionNumberResponse.Builder
- buildPartial() - Method in class io.grpc.reflection.v1alpha.ExtensionRequest.Builder
- buildPartial() - Method in class io.grpc.reflection.v1alpha.FileDescriptorResponse.Builder
- buildPartial() - Method in class io.grpc.reflection.v1alpha.ListServiceResponse.Builder
- buildPartial() - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest.Builder
- buildPartial() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
- buildPartial() - Method in class io.grpc.reflection.v1alpha.ServiceResponse.Builder
- buildPartial0(Address) - Method in class io.grpc.binarylog.v1.Address.Builder
- buildPartial0(ClientHeader) - Method in class io.grpc.binarylog.v1.ClientHeader.Builder
- buildPartial0(GrpcLogEntry) - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
- buildPartial0(Message) - Method in class io.grpc.binarylog.v1.Message.Builder
- buildPartial0(Metadata) - Method in class io.grpc.binarylog.v1.Metadata.Builder
- buildPartial0(MetadataEntry) - Method in class io.grpc.binarylog.v1.MetadataEntry.Builder
- buildPartial0(ServerHeader) - Method in class io.grpc.binarylog.v1.ServerHeader.Builder
- buildPartial0(Trailer) - Method in class io.grpc.binarylog.v1.Trailer.Builder
- buildPartial0(Address) - Method in class io.grpc.channelz.v1.Address.Builder
- buildPartial0(Address.OtherAddress) - Method in class io.grpc.channelz.v1.Address.OtherAddress.Builder
- buildPartial0(Address.TcpIpAddress) - Method in class io.grpc.channelz.v1.Address.TcpIpAddress.Builder
- buildPartial0(Address.UdsAddress) - Method in class io.grpc.channelz.v1.Address.UdsAddress.Builder
- buildPartial0(Channel) - Method in class io.grpc.channelz.v1.Channel.Builder
- buildPartial0(ChannelConnectivityState) - Method in class io.grpc.channelz.v1.ChannelConnectivityState.Builder
- buildPartial0(ChannelData) - Method in class io.grpc.channelz.v1.ChannelData.Builder
- buildPartial0(ChannelRef) - Method in class io.grpc.channelz.v1.ChannelRef.Builder
- buildPartial0(ChannelTrace) - Method in class io.grpc.channelz.v1.ChannelTrace.Builder
- buildPartial0(ChannelTraceEvent) - Method in class io.grpc.channelz.v1.ChannelTraceEvent.Builder
- buildPartial0(GetChannelRequest) - Method in class io.grpc.channelz.v1.GetChannelRequest.Builder
- buildPartial0(GetChannelResponse) - Method in class io.grpc.channelz.v1.GetChannelResponse.Builder
- buildPartial0(GetServerRequest) - Method in class io.grpc.channelz.v1.GetServerRequest.Builder
- buildPartial0(GetServerResponse) - Method in class io.grpc.channelz.v1.GetServerResponse.Builder
- buildPartial0(GetServerSocketsRequest) - Method in class io.grpc.channelz.v1.GetServerSocketsRequest.Builder
- buildPartial0(GetServerSocketsResponse) - Method in class io.grpc.channelz.v1.GetServerSocketsResponse.Builder
- buildPartial0(GetServersRequest) - Method in class io.grpc.channelz.v1.GetServersRequest.Builder
- buildPartial0(GetServersResponse) - Method in class io.grpc.channelz.v1.GetServersResponse.Builder
- buildPartial0(GetSocketRequest) - Method in class io.grpc.channelz.v1.GetSocketRequest.Builder
- buildPartial0(GetSocketResponse) - Method in class io.grpc.channelz.v1.GetSocketResponse.Builder
- buildPartial0(GetSubchannelRequest) - Method in class io.grpc.channelz.v1.GetSubchannelRequest.Builder
- buildPartial0(GetSubchannelResponse) - Method in class io.grpc.channelz.v1.GetSubchannelResponse.Builder
- buildPartial0(GetTopChannelsRequest) - Method in class io.grpc.channelz.v1.GetTopChannelsRequest.Builder
- buildPartial0(GetTopChannelsResponse) - Method in class io.grpc.channelz.v1.GetTopChannelsResponse.Builder
- buildPartial0(Security) - Method in class io.grpc.channelz.v1.Security.Builder
- buildPartial0(Security.OtherSecurity) - Method in class io.grpc.channelz.v1.Security.OtherSecurity.Builder
- buildPartial0(Security.Tls) - Method in class io.grpc.channelz.v1.Security.Tls.Builder
- buildPartial0(Server) - Method in class io.grpc.channelz.v1.Server.Builder
- buildPartial0(ServerData) - Method in class io.grpc.channelz.v1.ServerData.Builder
- buildPartial0(ServerRef) - Method in class io.grpc.channelz.v1.ServerRef.Builder
- buildPartial0(Socket) - Method in class io.grpc.channelz.v1.Socket.Builder
- buildPartial0(SocketData) - Method in class io.grpc.channelz.v1.SocketData.Builder
- buildPartial0(SocketOption) - Method in class io.grpc.channelz.v1.SocketOption.Builder
- buildPartial0(SocketOptionLinger) - Method in class io.grpc.channelz.v1.SocketOptionLinger.Builder
- buildPartial0(SocketOptionTcpInfo) - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
- buildPartial0(SocketOptionTimeout) - Method in class io.grpc.channelz.v1.SocketOptionTimeout.Builder
- buildPartial0(SocketRef) - Method in class io.grpc.channelz.v1.SocketRef.Builder
- buildPartial0(Subchannel) - Method in class io.grpc.channelz.v1.Subchannel.Builder
- buildPartial0(SubchannelRef) - Method in class io.grpc.channelz.v1.SubchannelRef.Builder
- buildPartial0(HealthCheckRequest) - Method in class io.grpc.health.v1.HealthCheckRequest.Builder
- buildPartial0(HealthCheckResponse) - Method in class io.grpc.health.v1.HealthCheckResponse.Builder
- buildPartial0(ClientStats) - Method in class io.grpc.lb.v1.ClientStats.Builder
- buildPartial0(ClientStatsPerToken) - Method in class io.grpc.lb.v1.ClientStatsPerToken.Builder
- buildPartial0(InitialLoadBalanceRequest) - Method in class io.grpc.lb.v1.InitialLoadBalanceRequest.Builder
- buildPartial0(InitialLoadBalanceResponse) - Method in class io.grpc.lb.v1.InitialLoadBalanceResponse.Builder
- buildPartial0(LoadBalanceRequest) - Method in class io.grpc.lb.v1.LoadBalanceRequest.Builder
- buildPartial0(LoadBalanceResponse) - Method in class io.grpc.lb.v1.LoadBalanceResponse.Builder
- buildPartial0(Server) - Method in class io.grpc.lb.v1.Server.Builder
- buildPartial0(ServerList) - Method in class io.grpc.lb.v1.ServerList.Builder
- buildPartial0(GrpcKeyBuilder) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
- buildPartial0(GrpcKeyBuilder.ExtraKeys) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys.Builder
- buildPartial0(GrpcKeyBuilder.Name) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Name.Builder
- buildPartial0(HttpKeyBuilder) - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
- buildPartial0(NameMatcher) - Method in class io.grpc.lookup.v1.NameMatcher.Builder
- buildPartial0(RouteLookupClusterSpecifier) - Method in class io.grpc.lookup.v1.RouteLookupClusterSpecifier.Builder
- buildPartial0(RouteLookupConfig) - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
- buildPartial0(RouteLookupRequest) - Method in class io.grpc.lookup.v1.RouteLookupRequest.Builder
- buildPartial0(RouteLookupResponse) - Method in class io.grpc.lookup.v1.RouteLookupResponse.Builder
- buildPartial0(ErrorResponse) - Method in class io.grpc.reflection.v1.ErrorResponse.Builder
- buildPartial0(ExtensionNumberResponse) - Method in class io.grpc.reflection.v1.ExtensionNumberResponse.Builder
- buildPartial0(ExtensionRequest) - Method in class io.grpc.reflection.v1.ExtensionRequest.Builder
- buildPartial0(FileDescriptorResponse) - Method in class io.grpc.reflection.v1.FileDescriptorResponse.Builder
- buildPartial0(ListServiceResponse) - Method in class io.grpc.reflection.v1.ListServiceResponse.Builder
- buildPartial0(ServerReflectionRequest) - Method in class io.grpc.reflection.v1.ServerReflectionRequest.Builder
- buildPartial0(ServerReflectionResponse) - Method in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
- buildPartial0(ServiceResponse) - Method in class io.grpc.reflection.v1.ServiceResponse.Builder
- buildPartial0(ErrorResponse) - Method in class io.grpc.reflection.v1alpha.ErrorResponse.Builder
- buildPartial0(ExtensionNumberResponse) - Method in class io.grpc.reflection.v1alpha.ExtensionNumberResponse.Builder
- buildPartial0(ExtensionRequest) - Method in class io.grpc.reflection.v1alpha.ExtensionRequest.Builder
- buildPartial0(FileDescriptorResponse) - Method in class io.grpc.reflection.v1alpha.FileDescriptorResponse.Builder
- buildPartial0(ListServiceResponse) - Method in class io.grpc.reflection.v1alpha.ListServiceResponse.Builder
- buildPartial0(ServerReflectionRequest) - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest.Builder
- buildPartial0(ServerReflectionResponse) - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
- buildPartial0(ServiceResponse) - Method in class io.grpc.reflection.v1alpha.ServiceResponse.Builder
- buildPartialOneofs(GrpcLogEntry) - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
- buildPartialOneofs(Address) - Method in class io.grpc.channelz.v1.Address.Builder
- buildPartialOneofs(ChannelTraceEvent) - Method in class io.grpc.channelz.v1.ChannelTraceEvent.Builder
- buildPartialOneofs(Security) - Method in class io.grpc.channelz.v1.Security.Builder
- buildPartialOneofs(Security.Tls) - Method in class io.grpc.channelz.v1.Security.Tls.Builder
- buildPartialOneofs(LoadBalanceRequest) - Method in class io.grpc.lb.v1.LoadBalanceRequest.Builder
- buildPartialOneofs(LoadBalanceResponse) - Method in class io.grpc.lb.v1.LoadBalanceResponse.Builder
- buildPartialOneofs(ServerReflectionRequest) - Method in class io.grpc.reflection.v1.ServerReflectionRequest.Builder
- buildPartialOneofs(ServerReflectionResponse) - Method in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
- buildPartialOneofs(ServerReflectionRequest) - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest.Builder
- buildPartialOneofs(ServerReflectionResponse) - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
- buildPartialRepeatedFields(Metadata) - Method in class io.grpc.binarylog.v1.Metadata.Builder
- buildPartialRepeatedFields(Channel) - Method in class io.grpc.channelz.v1.Channel.Builder
- buildPartialRepeatedFields(ChannelTrace) - Method in class io.grpc.channelz.v1.ChannelTrace.Builder
- buildPartialRepeatedFields(GetServerSocketsResponse) - Method in class io.grpc.channelz.v1.GetServerSocketsResponse.Builder
- buildPartialRepeatedFields(GetServersResponse) - Method in class io.grpc.channelz.v1.GetServersResponse.Builder
- buildPartialRepeatedFields(GetTopChannelsResponse) - Method in class io.grpc.channelz.v1.GetTopChannelsResponse.Builder
- buildPartialRepeatedFields(Server) - Method in class io.grpc.channelz.v1.Server.Builder
- buildPartialRepeatedFields(SocketData) - Method in class io.grpc.channelz.v1.SocketData.Builder
- buildPartialRepeatedFields(Subchannel) - Method in class io.grpc.channelz.v1.Subchannel.Builder
- buildPartialRepeatedFields(ClientStats) - Method in class io.grpc.lb.v1.ClientStats.Builder
- buildPartialRepeatedFields(ServerList) - Method in class io.grpc.lb.v1.ServerList.Builder
- buildPartialRepeatedFields(GrpcKeyBuilder) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
- buildPartialRepeatedFields(HttpKeyBuilder) - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
- buildPartialRepeatedFields(RouteLookupConfig) - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
- buildPartialRepeatedFields(ListServiceResponse) - Method in class io.grpc.reflection.v1.ListServiceResponse.Builder
- buildPartialRepeatedFields(ListServiceResponse) - Method in class io.grpc.reflection.v1alpha.ListServiceResponse.Builder
- buildProtocolNegotiator() - Method in interface io.grpc.netty.InternalNettyChannelBuilder.ProtocolNegotiatorFactory
- buildServlet() - Method in class io.grpc.servlet.jakarta.ServletServerBuilder
-
Creates a
GrpcServlet
. - buildServlet() - Method in class io.grpc.servlet.ServletServerBuilder
-
Creates a
GrpcServlet
. - buildServletAdapter() - Method in class io.grpc.servlet.jakarta.ServletServerBuilder
-
Creates a
ServletAdapter
. - buildServletAdapter() - Method in class io.grpc.servlet.ServletServerBuilder
-
Creates a
ServletAdapter
. - buildStatusList() - Static method in class io.grpc.Status
- buildTransportFactory() - Method in class io.grpc.inprocess.InProcessChannelBuilder
- buildTransportFactory() - Method in class io.grpc.netty.NettyChannelBuilder
- buildTransportFactory(NettyChannelBuilder) - Static method in class io.grpc.netty.InternalNettyChannelBuilder
- buildTransportServers(List<? extends ServerStreamTracer.Factory>) - Method in class io.grpc.inprocess.InProcessServerBuilder
- buildTransportServers(List<? extends ServerStreamTracer.Factory>) - Method in class io.grpc.netty.NettyServerBuilder
- buildTransportServers(List<? extends ServerStreamTracer.Factory>) - Method in class io.grpc.servlet.jakarta.ServletServerBuilder
- buildTransportServers(List<? extends ServerStreamTracer.Factory>) - Method in class io.grpc.servlet.ServletServerBuilder
- bundleMap - Variable in class io.grpc.internal.SpiffeUtil.SpiffeBundle
- BYTE_ARRAY_OP - Static variable in class io.grpc.internal.CompositeReadableBuffer
- BYTE_BUF_OP - Static variable in class io.grpc.internal.CompositeReadableBuffer
- BYTEARRAY_MARSHALLER - Static variable in class io.grpc.protobuf.services.BinaryLogProvider
- ByteArrayMarshaller() - Constructor for class io.grpc.protobuf.services.BinaryLogProvider.ByteArrayMarshaller
- ByteArrayWrapper(byte[]) - Constructor for class io.grpc.internal.ReadableBuffers.ByteArrayWrapper
- ByteArrayWrapper(byte[], int, int) - Constructor for class io.grpc.internal.ReadableBuffers.ByteArrayWrapper
- ByteArrayWritableBuffer(int) - Constructor for class io.grpc.servlet.jakarta.ServletServerStream.ByteArrayWritableBuffer
- ByteArrayWritableBuffer(int) - Constructor for class io.grpc.servlet.ServletServerStream.ByteArrayWritableBuffer
- bytebuf - Variable in class io.grpc.netty.NettyWritableBuffer
- bytebuf() - Method in class io.grpc.netty.NettyWritableBuffer
- ByteBufAllocatorPreferDirectHolder() - Constructor for class io.grpc.netty.Utils.ByteBufAllocatorPreferDirectHolder
- ByteBufAllocatorPreferHeapHolder() - Constructor for class io.grpc.netty.Utils.ByteBufAllocatorPreferHeapHolder
- byteBufferSupported() - Method in interface io.grpc.HasByteBuffer
-
Indicates whether or not
HasByteBuffer.getByteBuffer()
operation is supported. - byteBufferSupported() - Method in class io.grpc.internal.AbstractReadableBuffer
- byteBufferSupported() - Method in class io.grpc.internal.CompositeReadableBuffer
- byteBufferSupported() - Method in class io.grpc.internal.ForwardingReadableBuffer
- byteBufferSupported() - Method in interface io.grpc.internal.ReadableBuffer
-
Indicates whether or not
ReadableBuffer.getByteBuffer()
operation is supported for this buffer. - byteBufferSupported() - Method in class io.grpc.internal.ReadableBuffers.BufferInputStream
- byteBufferSupported() - Method in class io.grpc.internal.ReadableBuffers.ByteReadableBufferWrapper
- byteBufferSupported() - Method in class io.grpc.netty.NettyReadableBuffer
- ByteReadableBufferWrapper(ByteBuffer) - Constructor for class io.grpc.internal.ReadableBuffers.ByteReadableBufferWrapper
- bytes - Variable in class io.grpc.internal.ReadableBuffers.ByteArrayWrapper
- bytes - Variable in class io.grpc.internal.ReadableBuffers.ByteReadableBufferWrapper
- bytes - Variable in class io.grpc.servlet.jakarta.ServletServerStream.ByteArrayWritableBuffer
- bytes - Variable in class io.grpc.servlet.ServletServerStream.ByteArrayWritableBuffer
- bytes(AsciiString) - Static method in class io.grpc.netty.GrpcHttp2HeadersUtils.GrpcHttp2InboundHeaders
- bytes(CharSequence) - Static method in class io.grpc.netty.Utils
- BYTES_PER_CHAR - Static variable in class io.grpc.rls.CachingRlsLbClient
- bytesConsumed - Variable in class io.grpc.internal.GzipInflatingBuffer
-
Tracks gzipped bytes (including gzip metadata and deflated blocks) consumed during
GzipInflatingBuffer.inflateBytes(byte[], int, int)
calls. - bytesEqual(byte[], byte[]) - Method in class io.grpc.Metadata
- bytesRead(int) - Method in class io.grpc.internal.ApplicationThreadDeframerListener
- bytesRead(int) - Method in class io.grpc.internal.ForwardingDeframerListener
- bytesRead(int) - Method in interface io.grpc.internal.MessageDeframer.Listener
-
Called when the given number of bytes has been read from the input source of the deframer.
- bytesRead(int) - Method in class io.grpc.netty.NettyClientStream.TransportState
- bytesRead(int) - Method in class io.grpc.netty.NettyServerStream.TransportState
- bytesRead(int) - Method in class io.grpc.servlet.jakarta.ServletServerStream.ServletTransportState
- bytesRead(int) - Method in class io.grpc.servlet.ServletServerStream.ServletTransportState
C
- cache - Variable in class io.grpc.grpclb.CachedSubchannelPool
- cache(K, V) - Method in class io.grpc.rls.LinkedHashLruCache
- cache(K, V) - Method in interface io.grpc.rls.LruCache
-
Populates a cache entry.
- CACHE_ENTRIES_GAUGE - Static variable in class io.grpc.rls.CachingRlsLbClient
- CACHE_SIZE_BYTES_FIELD_NUMBER - Static variable in class io.grpc.lookup.v1.RouteLookupConfig
- CACHE_SIZE_GAUGE - Static variable in class io.grpc.rls.CachingRlsLbClient
- cacheAndClean(RlsProtoData.RouteLookupRequest, CachingRlsLbClient.CacheEntry) - Method in class io.grpc.rls.CachingRlsLbClient.RlsAsyncLruCache
- CachedRouteLookupResponse(CachingRlsLbClient.DataCacheEntry, CachingRlsLbClient.PendingCacheEntry, CachingRlsLbClient.BackoffCacheEntry) - Constructor for class io.grpc.rls.CachingRlsLbClient.CachedRouteLookupResponse
- CachedSubchannelPool - Class in io.grpc.grpclb
-
A
SubchannelPool
that keeps returnedLoadBalancer.Subchannel
s for a given time before it's shut down by the pool. - CachedSubchannelPool(LoadBalancer.Helper) - Constructor for class io.grpc.grpclb.CachedSubchannelPool
- CachedSubchannelPool.CacheEntry - Class in io.grpc.grpclb
- CachedSubchannelPool.ShutdownSubchannelTask - Class in io.grpc.grpclb
- CacheEntry(LoadBalancer.Subchannel, SynchronizationContext.ScheduledHandle, ConnectivityStateInfo) - Constructor for class io.grpc.grpclb.CachedSubchannelPool.CacheEntry
- CacheEntry(RlsProtoData.RouteLookupRequest) - Constructor for class io.grpc.rls.CachingRlsLbClient.CacheEntry
- cacheRefreshRequired() - Method in class io.grpc.internal.DnsNameResolver
- cacheSizeBytes - Variable in class io.grpc.rls.AutoValue_RlsProtoData_RouteLookupConfig.Builder
- cacheSizeBytes - Variable in class io.grpc.rls.AutoValue_RlsProtoData_RouteLookupConfig
- cacheSizeBytes() - Method in class io.grpc.rls.AutoValue_RlsProtoData_RouteLookupConfig
- cacheSizeBytes() - Method in class io.grpc.rls.RlsProtoData.RouteLookupConfig
-
Returns a rough indicator of amount of memory to use for the client cache.
- cacheSizeBytes(long) - Method in class io.grpc.rls.AutoValue_RlsProtoData_RouteLookupConfig.Builder
- cacheSizeBytes(long) - Method in class io.grpc.rls.RlsProtoData.RouteLookupConfig.Builder
- cacheSizeBytes_ - Variable in class io.grpc.lookup.v1.RouteLookupConfig.Builder
- cacheSizeBytes_ - Variable in class io.grpc.lookup.v1.RouteLookupConfig
- cacheTtlNanos - Variable in class io.grpc.internal.DnsNameResolver
- CachingRlsLbClient - Class in io.grpc.rls
-
A CachingRlsLbClient is a core implementation of RLS loadbalancer supports dynamic request routing by fetching the decision from route lookup server.
- CachingRlsLbClient(CachingRlsLbClient.Builder) - Constructor for class io.grpc.rls.CachingRlsLbClient
- CachingRlsLbClient.AutoCleaningEvictionListener - Class in io.grpc.rls
-
When any
CachingRlsLbClient.CacheEntry
is evicted fromLruCache
, it performsCachingRlsLbClient.CacheEntry.cleanup()
after originalLruCache.EvictionListener
is finished. - CachingRlsLbClient.BackoffCacheEntry - Class in io.grpc.rls
-
Implementation of
CachingRlsLbClient.CacheEntry
contains error. - CachingRlsLbClient.BackoffRefreshListener - Class in io.grpc.rls
-
LbStatusListener refreshes
CachingRlsLbClient.BackoffCacheEntry
when lb state is changed toConnectivityState.READY
fromConnectivityState.TRANSIENT_FAILURE
. - CachingRlsLbClient.Builder - Class in io.grpc.rls
-
A Builder for
CachingRlsLbClient
. - CachingRlsLbClient.CachedRouteLookupResponse - Class in io.grpc.rls
-
Viewer class for cached
RlsProtoData.RouteLookupResponse
and associatedLbPolicyConfiguration.ChildPolicyWrapper
. - CachingRlsLbClient.CacheEntry - Class in io.grpc.rls
-
Common cache entry data for
CachingRlsLbClient.RlsAsyncLruCache
. - CachingRlsLbClient.DataCacheEntry - Class in io.grpc.rls
-
Implementation of
CachingRlsLbClient.CacheEntry
contains valid data. - CachingRlsLbClient.HappyThrottler - Class in io.grpc.rls
-
A Throttler never throttles.
- CachingRlsLbClient.PendingCacheEntry - Class in io.grpc.rls
-
A pending cache entry when the async RouteLookup RPC is still on the fly.
- CachingRlsLbClient.RlsAsyncLruCache - Class in io.grpc.rls
-
Implementation of
LinkedHashLruCache
for RLS. - CachingRlsLbClient.RlsLbHelper - Class in io.grpc.rls
- CachingRlsLbClient.RlsPicker - Class in io.grpc.rls
- cachingRlsLbClientBuilderProvider - Variable in class io.grpc.rls.RlsLoadBalancer
- calcStringSize(String) - Method in class io.grpc.rls.CachingRlsLbClient.DataCacheEntry
- call - Variable in class io.grpc.internal.ServerCallImpl.ServerStreamListenerImpl
- call - Variable in class io.grpc.internal.ServerImpl.ServerTransportListenerImpl.ServerCallParameters
- call - Variable in class io.grpc.protobuf.services.HealthCheckingLoadBalancerFactory.HealthCheckState.HcStream
- call - Variable in class io.grpc.stub.ClientCalls.BlockingResponseStream
- call - Variable in class io.grpc.stub.ClientCalls.CallToStreamObserverAdapter
- call - Variable in class io.grpc.stub.ClientCalls.GrpcFuture
- call - Variable in class io.grpc.stub.ServerCalls.ServerCallStreamObserverImpl
- call - Variable in class io.grpc.stub.ServerCalls.StreamingServerCallHandler.StreamingServerCallListener
- call - Variable in class io.grpc.stub.ServerCalls.UnaryServerCallHandler.UnaryServerCallListener
- call(Callable<V>) - Method in class io.grpc.Context
-
Immediately call a
Callable
with this context as theContext.current()
context. - CALL_ID_FIELD_NUMBER - Static variable in class io.grpc.binarylog.v1.GrpcLogEntry
- CALL_OPTIONS_RPC_OWNED_BY_BALANCER - Static variable in class io.grpc.internal.GrpcUtil
-
RPCs created on the Channel returned by
LoadBalancer.Subchannel.asChannel()
will have this option with valuetrue
. - callback - Variable in class io.grpc.internal.ConnectivityStateManager.Listener
- callback - Variable in class io.grpc.internal.InternalSubchannel
- callback - Variable in class io.grpc.netty.SendPingCommand
- callback() - Method in class io.grpc.netty.SendPingCommand
- Callback() - Constructor for class io.grpc.internal.InternalSubchannel.Callback
- CallbackMetricInstrument - Interface in io.grpc
-
Tagging interface for MetricInstruments that can be used with batch callbacks.
- callbacks - Variable in class io.grpc.internal.Http2Ping
-
The registered callbacks and the executor used to invoke them.
- callCancelled() - Method in class io.grpc.internal.DelayedClientCall
- callCancelled() - Method in class io.grpc.internal.ManagedChannelImpl.RealChannel.PendingCall
- CallCounter() - Constructor for class io.grpc.util.OutlierDetectionLoadBalancer.EndpointTracker.CallCounter
- callCreationTime - Variable in class io.grpc.internal.ManagedChannelImpl.RealChannel.PendingCall
- callCredentials - Variable in class io.grpc.CompositeChannelCredentials
- callCredentials - Variable in class io.grpc.internal.ClientTransportFactory.SwapChannelCredentialsResult
- callCredentials - Variable in class io.grpc.internal.ManagedChannelImplBuilder
- callCredentials - Variable in class io.grpc.netty.ProtocolNegotiators.FromChannelCredentialsResult
- CallCredentials - Class in io.grpc
-
Carries credential data that will be propagated to the server via request metadata for each RPC.
- CallCredentials() - Constructor for class io.grpc.CallCredentials
- CallCredentials.MetadataApplier - Class in io.grpc
-
The outlet of the produced headers.
- CallCredentials.RequestInfo - Class in io.grpc
-
The request-related information passed to
CallCredentials.applyRequestMetadata()
. - CallCredentialsApplyingTransport(ConnectionClientTransport, String) - Constructor for class io.grpc.internal.CallCredentialsApplyingTransportFactory.CallCredentialsApplyingTransport
- CallCredentialsApplyingTransportFactory - Class in io.grpc.internal
- CallCredentialsApplyingTransportFactory(ClientTransportFactory, CallCredentials, Executor) - Constructor for class io.grpc.internal.CallCredentialsApplyingTransportFactory
- CallCredentialsApplyingTransportFactory.CallCredentialsApplyingTransport - Class in io.grpc.internal
- callExecutor - Variable in class io.grpc.internal.ClientCallImpl
- callExecutor - Variable in class io.grpc.internal.DelayedClientCall
- callExecutor - Variable in class io.grpc.internal.ManagedChannelImpl.ConfigSelectingClientCall
- callExecutor - Variable in class io.grpc.internal.RetriableStream
- callExecutor - Variable in class io.grpc.internal.ServerImpl.JumpToApplicationThreadServerStreamListener
- callExecutor(ServerCallExecutorSupplier) - Method in class io.grpc.ForwardingServerBuilder
- callExecutor(ServerCallExecutorSupplier) - Method in class io.grpc.internal.ServerImplBuilder
- callExecutor(ServerCallExecutorSupplier) - Method in class io.grpc.ServerBuilder
-
Allows for defining a way to provide a custom executor to handle the server call.
- callExecutorIsDirect - Variable in class io.grpc.internal.ClientCallImpl
- callHandler - Variable in class io.grpc.internal.ServerImpl.ServerTransportListenerImpl.ServerCallParameters
- callHandler - Variable in class io.grpc.ServerInterceptors.InterceptCallHandler
- callHasResponded - Variable in class io.grpc.protobuf.services.HealthCheckingLoadBalancerFactory.HealthCheckState.HcStream
- callId_ - Variable in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
- callId_ - Variable in class io.grpc.binarylog.v1.GrpcLogEntry
- callInfo - Variable in class io.grpc.ServerStreamTracer.ReadOnlyServerCall
-
Deprecated.
- CallMetricRecorder - Class in io.grpc.services
-
Utility to record call metrics for load-balancing.
- CallMetricRecorder() - Constructor for class io.grpc.services.CallMetricRecorder
- callOptions - Variable in class io.grpc.ClientStreamTracer.StreamInfo.Builder
- callOptions - Variable in class io.grpc.ClientStreamTracer.StreamInfo
- callOptions - Variable in class io.grpc.inprocess.InProcessTransport.InProcessStream
- callOptions - Variable in class io.grpc.inprocess.InProcessTransport.InProcessStream.InProcessClientStream
- callOptions - Variable in class io.grpc.internal.ClientCallImpl
- callOptions - Variable in class io.grpc.internal.ManagedChannelImpl.ConfigSelectingClientCall
- callOptions - Variable in class io.grpc.internal.ManagedChannelImpl.RealChannel.PendingCall
- callOptions - Variable in class io.grpc.internal.MetadataApplierImpl
- callOptions - Variable in class io.grpc.internal.PickSubchannelArgsImpl
- callOptions - Variable in class io.grpc.stub.AbstractStub
- CallOptions - Class in io.grpc
-
The collection of runtime options for a new RPC call.
- CallOptions(CallOptions.Builder) - Constructor for class io.grpc.CallOptions
- CallOptions.Builder - Class in io.grpc
- CallOptions.Key<T> - Class in io.grpc
-
Key for a key-value pair.
- CALLS_FAILED_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.ChannelData
- CALLS_FAILED_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.ServerData
- CALLS_FINISHED_WITH_DROP_FIELD_NUMBER - Static variable in class io.grpc.lb.v1.ClientStats
- CALLS_STARTED_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.ChannelData
- CALLS_STARTED_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.ServerData
- CALLS_SUCCEEDED_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.ChannelData
- CALLS_SUCCEEDED_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.ServerData
- callsDroppedPerToken - Variable in class io.grpc.grpclb.GrpclbClientLoadRecorder
- callServiceName - Variable in class io.grpc.protobuf.services.HealthCheckingLoadBalancerFactory.HealthCheckState.HcStream
- callsFailed - Variable in class io.grpc.internal.CallTracer
- callsFailed - Variable in class io.grpc.InternalChannelz.ChannelStats.Builder
- callsFailed - Variable in class io.grpc.InternalChannelz.ChannelStats
- callsFailed - Variable in class io.grpc.InternalChannelz.ServerStats.Builder
- callsFailed - Variable in class io.grpc.InternalChannelz.ServerStats
- callsFailed_ - Variable in class io.grpc.channelz.v1.ChannelData.Builder
- callsFailed_ - Variable in class io.grpc.channelz.v1.ChannelData
- callsFailed_ - Variable in class io.grpc.channelz.v1.ServerData.Builder
- callsFailed_ - Variable in class io.grpc.channelz.v1.ServerData
- callsFailedToSend - Variable in class io.grpc.grpclb.GrpclbClientLoadRecorder
- callsFailedToSendUpdater - Static variable in class io.grpc.grpclb.GrpclbClientLoadRecorder
- callsFinished - Variable in class io.grpc.grpclb.GrpclbClientLoadRecorder
- callsFinishedKnownReceived - Variable in class io.grpc.grpclb.GrpclbClientLoadRecorder
- callsFinishedKnownReceivedUpdater - Static variable in class io.grpc.grpclb.GrpclbClientLoadRecorder
- callsFinishedUpdater - Static variable in class io.grpc.grpclb.GrpclbClientLoadRecorder
- callsFinishedWithDrop_ - Variable in class io.grpc.lb.v1.ClientStats.Builder
- callsFinishedWithDrop_ - Variable in class io.grpc.lb.v1.ClientStats
- callsFinishedWithDropBuilder_ - Variable in class io.grpc.lb.v1.ClientStats.Builder
- callsStarted - Variable in class io.grpc.grpclb.GrpclbClientLoadRecorder
- callsStarted - Variable in class io.grpc.internal.CallTracer
- callsStarted - Variable in class io.grpc.InternalChannelz.ChannelStats.Builder
- callsStarted - Variable in class io.grpc.InternalChannelz.ChannelStats
- callsStarted - Variable in class io.grpc.InternalChannelz.ServerStats.Builder
- callsStarted - Variable in class io.grpc.InternalChannelz.ServerStats
- callsStarted_ - Variable in class io.grpc.channelz.v1.ChannelData.Builder
- callsStarted_ - Variable in class io.grpc.channelz.v1.ChannelData
- callsStarted_ - Variable in class io.grpc.channelz.v1.ServerData.Builder
- callsStarted_ - Variable in class io.grpc.channelz.v1.ServerData
- callsStartedUpdater - Static variable in class io.grpc.grpclb.GrpclbClientLoadRecorder
- callsSucceeded - Variable in class io.grpc.internal.CallTracer
- callsSucceeded - Variable in class io.grpc.InternalChannelz.ChannelStats.Builder
- callsSucceeded - Variable in class io.grpc.InternalChannelz.ChannelStats
- callsSucceeded - Variable in class io.grpc.InternalChannelz.ServerStats.Builder
- callsSucceeded - Variable in class io.grpc.InternalChannelz.ServerStats
- callsSucceeded_ - Variable in class io.grpc.channelz.v1.ChannelData.Builder
- callsSucceeded_ - Variable in class io.grpc.channelz.v1.ChannelData
- callsSucceeded_ - Variable in class io.grpc.channelz.v1.ServerData.Builder
- callsSucceeded_ - Variable in class io.grpc.channelz.v1.ServerData
- callsTracer - Variable in class io.grpc.internal.InternalSubchannel
- callsTracer - Variable in class io.grpc.internal.SubchannelChannel
- CallStreamObserver<V> - Class in io.grpc.stub
-
A refinement of StreamObserver provided by the GRPC runtime to the application (the client or the server) that allows for more complex interactions with call behavior.
- CallStreamObserver() - Constructor for class io.grpc.stub.CallStreamObserver
- callTimeoutNanos - Variable in class io.grpc.rls.CachingRlsLbClient
- CallToStreamObserverAdapter(ClientCall<ReqT, ?>, boolean) - Constructor for class io.grpc.stub.ClientCalls.CallToStreamObserverAdapter
- callTracer - Variable in class io.grpc.internal.InternalSubchannel.CallTracingTransport
- CallTracer - Class in io.grpc.internal
-
A collection of call stats for channelz.
- CallTracer(TimeProvider) - Constructor for class io.grpc.internal.CallTracer
- CallTracer.Factory - Interface in io.grpc.internal
- callTracerFactory - Variable in class io.grpc.internal.ManagedChannelImpl
- callTracerFactory - Variable in class io.grpc.internal.ServerImplBuilder
- CallTracingTransport(ConnectionClientTransport, CallTracer) - Constructor for class io.grpc.internal.InternalSubchannel.CallTracingTransport
- cancel() - Method in class io.grpc.SynchronizationContext.ScheduledHandle
-
Cancel the task if it's still
pending
. - cancel(boolean) - Method in class io.grpc.internal.Rescheduler
- cancel(Status) - Method in class io.grpc.inprocess.InProcessTransport.InProcessStream.InProcessClientStream
- cancel(Status) - Method in class io.grpc.inprocess.InProcessTransport.InProcessStream.InProcessServerStream
- 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.DelayedClientTransport.PendingStream
- cancel(Status) - Method in class io.grpc.internal.DelayedStream
- cancel(Status) - Method in class io.grpc.internal.ForwardingClientStream
- cancel(Status) - Method in class io.grpc.internal.NoopClientStream
- cancel(Status) - Method in class io.grpc.internal.RetriableStream
- cancel(Status) - Method in interface io.grpc.internal.ServerStream
-
Tears down the stream, typically in the event of a timeout.
- cancel(Status) - Method in class io.grpc.netty.NettyClientStream.Sink
- cancel(Status) - Method in class io.grpc.netty.NettyServerStream.Sink
- cancel(Status) - Method in class io.grpc.servlet.jakarta.ServletServerStream.Sink
- cancel(Status) - Method in class io.grpc.servlet.ServletServerStream.Sink
- cancel(Status, boolean) - Method in class io.grpc.internal.DelayedClientCall
-
Cancels the call unless
realCall
is set andonlyCancelPendingCall
is true. - cancel(String) - Method in class io.grpc.protobuf.services.HealthCheckingLoadBalancerFactory.HealthCheckState.HcStream
- cancel(String, Throwable) - Method in class io.grpc.ClientCall
-
Prevent any further processing for this
ClientCall
. - cancel(String, Throwable) - Method in class io.grpc.internal.ClientCallImpl
- cancel(String, Throwable) - Method in class io.grpc.internal.DelayedClientCall
- cancel(String, Throwable) - Method in class io.grpc.internal.ManagedChannelImpl.ConfigSelectingClientCall
- cancel(String, Throwable) - Method in class io.grpc.PartialForwardingClientCall
- cancel(String, Throwable) - Method in class io.grpc.stub.ClientCalls.CallToStreamObserverAdapter
- cancel(String, Throwable) - Method in class io.grpc.stub.ClientCallStreamObserver
-
Prevent any further processing for this
ClientCallStreamObserver
. - cancel(Throwable) - Method in class io.grpc.Context.CancellableContext
-
Cancel this context and optionally provide a cause (can be
null
) for the cancellation. - CANCEL - Enum constant in enum io.grpc.internal.GrpcUtil.Http2Error
- cancelCalled - Variable in class io.grpc.internal.ClientCallImpl
- CancelClientStreamCommand - Class in io.grpc.netty
-
Command sent from a Netty client stream to the handler to cancel the stream.
- CancelClientStreamCommand(NettyClientStream.TransportState, Status) - Constructor for class io.grpc.netty.CancelClientStreamCommand
- cancelExecutor - Variable in class io.grpc.internal.ServerImpl.JumpToApplicationThreadServerStreamListener
- cancelFallbackTimer() - Method in class io.grpc.grpclb.GrpclbState
- cancelIdleTimer(boolean) - Method in class io.grpc.internal.ManagedChannelImpl
- cancelInternal(String, Throwable) - Method in class io.grpc.internal.ClientCallImpl
- cancellableAncestor - Variable in class io.grpc.Context
- cancellableAncestor(Context) - Static method in class io.grpc.Context
-
Returns
parent
if it is aContext.CancellableContext
, otherwise returns the parent'sContext.cancellableAncestor
. - CancellableContext(Context) - Constructor for class io.grpc.Context.CancellableContext
-
Create a cancellable context that does not have a deadline.
- CancellableContext(Context, Deadline) - Constructor for class io.grpc.Context.CancellableContext
-
Create a cancellable context that has a deadline.
- cancellationCause - Variable in class io.grpc.Context.CancellableContext
- cancellationCause() - Method in class io.grpc.Context.CancellableContext
- cancellationCause() - Method in class io.grpc.Context
-
If a context
Context.isCancelled()
then return the cause of the cancellation ornull
if context was cancelled without a cause. - cancellationHandler - Variable in class io.grpc.internal.ClientCallImpl
- CancellationHandler(Deadline, boolean) - Constructor for class io.grpc.internal.ClientCallImpl.CancellationHandler
- cancellationStatus - Variable in class io.grpc.internal.RetriableStream
- cancelLbRpcRetryTimer() - Method in class io.grpc.grpclb.GrpclbState
- cancelled - Variable in class io.grpc.Context.CancellableContext
- cancelled - Variable in class io.grpc.internal.AbstractClientStream
-
Whether cancel() has been called.
- cancelled - Variable in class io.grpc.internal.RetriableStream.FutureCanceller
- cancelled - Variable in class io.grpc.internal.RetriableStream.State
-
Not required to set to true when cancelled, but can short-circuit the draining process.
- cancelled - Variable in class io.grpc.internal.ServerCallImpl
- cancelled - Variable in class io.grpc.stub.ServerCalls.ServerCallStreamObserverImpl
- cancelled() - Method in class io.grpc.internal.RetriableStream.State
- cancelled(Context) - Method in interface io.grpc.Context.CancellationListener
-
Notifies that a context was cancelled.
- cancelled(Context) - Method in class io.grpc.internal.ClientCallImpl.CancellationHandler
- CANCELLED - Enum constant in enum io.grpc.Status.Code
-
The operation was cancelled (typically by the caller).
- CANCELLED - Static variable in class io.grpc.Status
-
The operation was cancelled (typically by the caller).
- CANCELLED_BECAUSE_COMMITTED - Static variable in class io.grpc.internal.RetriableStream
- cancelPing(Throwable) - Method in class io.grpc.netty.NettyClientHandler
- cancelReconnectTask() - Method in class io.grpc.internal.InternalSubchannel
- cancelScheduleTask() - Method in class io.grpc.internal.PickFirstLeafLoadBalancer
- CancelServerStreamCommand - Class in io.grpc.netty
-
Command sent from a Netty server stream to the handler to cancel the stream.
- CancelServerStreamCommand(NettyServerStream.TransportState, Status, CancelServerStreamCommand.PeerNotify) - Constructor for class io.grpc.netty.CancelServerStreamCommand
- CancelServerStreamCommand.PeerNotify - Enum in io.grpc.netty
- cancelStream(ChannelHandlerContext, CancelClientStreamCommand, ChannelPromise) - Method in class io.grpc.netty.NettyClientHandler
-
Cancels this stream.
- cancelStream(ChannelHandlerContext, CancelServerStreamCommand, ChannelPromise) - Method in class io.grpc.netty.NettyServerHandler
- cancelThrow(ClientCall<?, ?>, Throwable) - Static method in class io.grpc.stub.ClientCalls
-
Cancels a call, and throws the exception.
- cancelTracking() - Method in class io.grpc.util.OutlierDetectionLoadBalancer.EndpointTrackerMap
-
When OD gets disabled we need to uneject any subchannels that may have been ejected and to reset the ejection time multiplier.
- canHandleEmptyAddressListFromNameResolution() - Method in class io.grpc.grpclb.GrpclbLoadBalancer
- canHandleEmptyAddressListFromNameResolution() - Method in class io.grpc.LoadBalancer
-
Whether this LoadBalancer can handle empty address group list to be passed to
LoadBalancer.handleResolvedAddresses(ResolvedAddresses)
. - canHandleEmptyAddressListFromNameResolution() - Method in class io.grpc.util.ForwardingLoadBalancer
- canInvoke - Variable in class io.grpc.stub.ServerCalls.UnaryServerCallHandler.UnaryServerCallListener
- cap() - Method in class io.grpc.Metadata
- capacity - Variable in class io.grpc.servlet.jakarta.ServletServerStream.ByteArrayWritableBuffer
- capacity - Variable in class io.grpc.servlet.ServletServerStream.ByteArrayWritableBuffer
- caState - Variable in class io.grpc.InternalChannelz.TcpInfo.Builder
- caState - Variable in class io.grpc.InternalChannelz.TcpInfo
- cause - Variable in class io.grpc.internal.ServerImpl.ContextCloser
- cause - Static variable in class io.grpc.netty.JettyTlsUtil.Java9AlpnUnavailabilityCauseHolder
- cause - Variable in class io.grpc.Status
- certFile - Variable in class io.grpc.util.AdvancedTlsX509KeyManager.LoadFilePathExecution
- CERTIFICATE_AND_HOST_NAME_VERIFICATION - Enum constant in enum io.grpc.util.AdvancedTlsX509TrustManager.Verification
-
This is the DEFAULT and RECOMMENDED mode for most applications.
- CERTIFICATE_ONLY_VERIFICATION - Enum constant in enum io.grpc.util.AdvancedTlsX509TrustManager.Verification
-
DANGEROUS: Use trusted credentials to verify the certificate, but clients will not verify the certificate is for the expected host.
- CERTIFICATE_PREFIX - Static variable in class io.grpc.internal.SpiffeUtil
- CERTIFICATE_SUFFIX - Static variable in class io.grpc.internal.SpiffeUtil
- certificateChain - Variable in class io.grpc.TlsChannelCredentials.Builder
- certificateChain - Variable in class io.grpc.TlsChannelCredentials
- certificateChain - Variable in class io.grpc.TlsServerCredentials.Builder
- certificateChain - Variable in class io.grpc.TlsServerCredentials
- CertificateUtils - Class in io.grpc.util
-
Contains certificate/key PEM file utility method(s).
- CertificateUtils() - Constructor for class io.grpc.util.CertificateUtils
- certs - Variable in class io.grpc.util.AdvancedTlsX509KeyManager.KeyInfo
- certTime - Variable in class io.grpc.util.AdvancedTlsX509KeyManager.UpdateResult
- ch - Variable in class io.grpc.netty.NettyServer.ListenSocket
- channel - Variable in class io.grpc.ClientInterceptors.InterceptorChannel
- channel - Variable in class io.grpc.internal.ManagedChannelImpl.ConfigSelectingClientCall
- channel - Variable in class io.grpc.netty.NettyClientTransport
- channel - Variable in class io.grpc.netty.NettyServerTransport
- channel - Variable in class io.grpc.netty.WriteQueue
- channel - Variable in class io.grpc.stub.AbstractStub
- channel() - Method in class io.grpc.netty.NettyClientTransport
- channel() - Method in class io.grpc.netty.NettyServerTransport
-
For testing purposes only.
- Channel - Class in io.grpc
-
A virtual connection to a conceptual endpoint, to perform RPCs.
- Channel - Class in io.grpc.channelz.v1
-
Channel is a logical grouping of channels, subchannels, and sockets.
- Channel() - Constructor for class io.grpc.Channel
- Channel() - Constructor for class io.grpc.channelz.v1.Channel
- Channel(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.channelz.v1.Channel
- channel_ - Variable in class io.grpc.channelz.v1.GetChannelResponse.Builder
- channel_ - Variable in class io.grpc.channelz.v1.GetChannelResponse
- channel_ - Variable in class io.grpc.channelz.v1.GetTopChannelsResponse.Builder
- channel_ - Variable in class io.grpc.channelz.v1.GetTopChannelsResponse
- CHANNEL_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.GetChannelResponse
- CHANNEL_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.GetTopChannelsResponse
- CHANNEL_ID_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.ChannelRef
- CHANNEL_ID_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.GetChannelRequest
- CHANNEL_REF - Enum constant in enum io.grpc.channelz.v1.ChannelTraceEvent.ChildRefCase
- CHANNEL_REF_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.Channel
- CHANNEL_REF_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.ChannelTraceEvent
- CHANNEL_REF_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.Subchannel
- Channel.Builder - Class in io.grpc.channelz.v1
-
Channel is a logical grouping of channels, subchannels, and sockets.
- channelActive(ChannelHandlerContext) - Method in class io.grpc.netty.AbstractNettyHandler
- channelActive(ChannelHandlerContext) - Method in class io.grpc.netty.ProtocolNegotiators.WaitUntilActiveHandler
- channelBufferLimit - Variable in class io.grpc.internal.ManagedChannelImpl
- channelBufferLimit - Variable in class io.grpc.internal.RetriableStream
- ChannelBufferMeter() - Constructor for class io.grpc.internal.RetriableStream.ChannelBufferMeter
- channelBufferUsed - Variable in class io.grpc.internal.ManagedChannelImpl
- channelBufferUsed - Variable in class io.grpc.internal.RetriableStream
- channelBuilder - Variable in class io.grpc.ManagedChannelProvider.NewChannelBuilderResult
- channelBuilder(ManagedChannelBuilder<?>) - Static method in class io.grpc.ManagedChannelProvider.NewChannelBuilderResult
- channelBuilder_ - Variable in class io.grpc.channelz.v1.GetChannelResponse.Builder
- channelBuilder_ - Variable in class io.grpc.channelz.v1.GetTopChannelsResponse.Builder
- channelBuilderDefaultPortProvider - Variable in class io.grpc.internal.ManagedChannelImplBuilder
- channelCallCredentials - Variable in class io.grpc.internal.CallCredentialsApplyingTransportFactory
- channelCallsTracer - Variable in class io.grpc.internal.ClientCallImpl
- channelCallsTracer - Variable in class io.grpc.internal.OobChannel
- channelCallTracer - Variable in class io.grpc.internal.ManagedChannelImpl
- ChannelConnectivityState - Class in io.grpc.channelz.v1
-
These come from the specified states in this document: https://github.com/grpc/grpc/blob/master/doc/connectivity-semantics-and-api.md
- ChannelConnectivityState() - Constructor for class io.grpc.channelz.v1.ChannelConnectivityState
- ChannelConnectivityState(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.channelz.v1.ChannelConnectivityState
- ChannelConnectivityState.Builder - Class in io.grpc.channelz.v1
-
These come from the specified states in this document: https://github.com/grpc/grpc/blob/master/doc/connectivity-semantics-and-api.md
- ChannelConnectivityState.State - Enum in io.grpc.channelz.v1
-
Protobuf enum
grpc.channelz.v1.ChannelConnectivityState.State
- ChannelConnectivityStateOrBuilder - Interface in io.grpc.channelz.v1
- channelCreationTimeNanos - Variable in class io.grpc.internal.ChannelTracer
- channelCredentials - Variable in class io.grpc.CompositeChannelCredentials
- channelCredentials - Variable in class io.grpc.internal.ManagedChannelImplBuilder
- ChannelCredentials - Class in io.grpc
-
Represents a security configuration to be used for channels.
- ChannelCredentials() - Constructor for class io.grpc.ChannelCredentials
- ChannelData - Class in io.grpc.channelz.v1
-
Channel data is data related to a specific Channel or Subchannel.
- ChannelData() - Constructor for class io.grpc.channelz.v1.ChannelData
- ChannelData(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.channelz.v1.ChannelData
- ChannelData.Builder - Class in io.grpc.channelz.v1
-
Channel data is data related to a specific Channel or Subchannel.
- ChannelDataOrBuilder - Interface in io.grpc.channelz.v1
- channelFactory - Variable in class io.grpc.netty.NettyChannelBuilder
- channelFactory - Variable in class io.grpc.netty.NettyChannelBuilder.NettyTransportFactory
- channelFactory - Variable in class io.grpc.netty.NettyClientTransport
- channelFactory - Variable in class io.grpc.netty.NettyServer
- channelFactory - Variable in class io.grpc.netty.NettyServerBuilder
- channelFactory(ChannelFactory<? extends Channel>) - Method in class io.grpc.netty.NettyChannelBuilder
-
Specifies the
ChannelFactory
to createChannel
instances. - channelFactory(ChannelFactory<? extends Channel>, Class<? extends SocketAddress>) - Method in class io.grpc.netty.NettyChannelBuilder
-
Similar to
NettyChannelBuilder.channelFactory(ChannelFactory)
above but allows the caller to specify the socket-type associated with the channelFactory. - channelFactory(ChannelFactory<? extends ServerChannel>) - Method in class io.grpc.netty.NettyServerBuilder
-
Specifies the
ChannelFactory
to createServerChannel
instances. - ChannelFutureRunnable() - Constructor for class io.grpc.internal.Rescheduler.ChannelFutureRunnable
- channelGroup - Variable in class io.grpc.netty.NettyServer
- channelId_ - Variable in class io.grpc.channelz.v1.ChannelRef.Builder
- channelId_ - Variable in class io.grpc.channelz.v1.ChannelRef
- channelId_ - Variable in class io.grpc.channelz.v1.GetChannelRequest.Builder
- channelId_ - Variable in class io.grpc.channelz.v1.GetChannelRequest
- channelInactive(ChannelHandlerContext) - Method in class io.grpc.netty.NettyClientHandler
-
Handler for the Channel shutting down.
- channelInactive(ChannelHandlerContext) - Method in class io.grpc.netty.NettyServerHandler
-
Handler for the Channel shutting down.
- channelInactive(ChannelHandlerContext) - Method in class io.grpc.netty.WriteBufferingAndExceptionHandler
-
If this channel becomes inactive, then notify all buffered writes that we failed.
- channelInactiveReason - Variable in class io.grpc.netty.NettyClientHandler
- channelLogger - Variable in class io.grpc.internal.ClientTransportFactory.ClientTransportOptions
- channelLogger - Variable in class io.grpc.internal.InternalSubchannel
- channelLogger - Variable in class io.grpc.internal.ManagedChannelImpl
- channelLogger - Variable in class io.grpc.NameResolver.Args.Builder
- channelLogger - Variable in class io.grpc.NameResolver.Args
- channelLogger - Variable in class io.grpc.netty.NettyClientTransport
- ChannelLogger - Class in io.grpc
-
A Channel-specific logger provided by GRPC library to
LoadBalancer
implementations. - ChannelLogger() - Constructor for class io.grpc.ChannelLogger
- ChannelLogger.ChannelLogLevel - Enum in io.grpc
-
Log levels.
- ChannelLoggerImpl - Class in io.grpc.internal
- ChannelLoggerImpl(ChannelTracer, TimeProvider) - Constructor for class io.grpc.internal.ChannelLoggerImpl
- ChannelLogLevel() - Constructor for enum io.grpc.ChannelLogger.ChannelLogLevel
- channelOptions - Variable in class io.grpc.netty.NettyChannelBuilder
- channelOptions - Variable in class io.grpc.netty.NettyChannelBuilder.NettyTransportFactory
- channelOptions - Variable in class io.grpc.netty.NettyClientTransport
- channelOptions - Variable in class io.grpc.netty.NettyServer
- channelOptions - Variable in class io.grpc.netty.NettyServerBuilder
- ChannelOrBuilder - Interface in io.grpc.channelz.v1
- channelRead(ChannelHandlerContext, Object) - Method in class io.grpc.netty.WriteBufferingAndExceptionHandler
- channelRef - Variable in class io.grpc.InternalChannelz.ChannelTrace.Event.Builder
- channelRef - Variable in class io.grpc.InternalChannelz.ChannelTrace.Event
- ChannelRef - Class in io.grpc.channelz.v1
-
ChannelRef is a reference to a Channel.
- ChannelRef() - Constructor for class io.grpc.channelz.v1.ChannelRef
- ChannelRef(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.channelz.v1.ChannelRef
- channelRef_ - Variable in class io.grpc.channelz.v1.Channel.Builder
- channelRef_ - Variable in class io.grpc.channelz.v1.Channel
- channelRef_ - Variable in class io.grpc.channelz.v1.Subchannel.Builder
- channelRef_ - Variable in class io.grpc.channelz.v1.Subchannel
- ChannelRef.Builder - Class in io.grpc.channelz.v1
-
ChannelRef is a reference to a Channel.
- channelRefBuilder_ - Variable in class io.grpc.channelz.v1.Channel.Builder
- channelRefBuilder_ - Variable in class io.grpc.channelz.v1.ChannelTraceEvent.Builder
- channelRefBuilder_ - Variable in class io.grpc.channelz.v1.Subchannel.Builder
- ChannelRefOrBuilder - Interface in io.grpc.channelz.v1
- channels - Variable in class io.grpc.InternalChannelz.RootChannelList
- channelStateManager - Variable in class io.grpc.internal.ManagedChannelImpl
- ChannelStats(String, ConnectivityState, InternalChannelz.ChannelTrace, long, long, long, long, List<InternalWithLogId>, List<InternalWithLogId>) - Constructor for class io.grpc.InternalChannelz.ChannelStats
-
Creates an instance.
- channelStr - Variable in class io.grpc.internal.ManagedChannelOrphanWrapper.ManagedChannelReference
- ChannelStreamProvider() - Constructor for class io.grpc.internal.ManagedChannelImpl.ChannelStreamProvider
- channelTrace - Variable in class io.grpc.InternalChannelz.ChannelStats.Builder
- channelTrace - Variable in class io.grpc.InternalChannelz.ChannelStats
- ChannelTrace - Class in io.grpc.channelz.v1
-
ChannelTrace represents the recent events that have occurred on the channel.
- ChannelTrace() - Constructor for class io.grpc.channelz.v1.ChannelTrace
- ChannelTrace(long, long, List<InternalChannelz.ChannelTrace.Event>) - Constructor for class io.grpc.InternalChannelz.ChannelTrace
- ChannelTrace(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.channelz.v1.ChannelTrace
- ChannelTrace.Builder - Class in io.grpc.channelz.v1
-
ChannelTrace represents the recent events that have occurred on the channel.
- ChannelTraceEvent - Class in io.grpc.channelz.v1
-
A trace event is an interesting thing that happened to a channel or subchannel, such as creation, address resolution, subchannel creation, etc.
- ChannelTraceEvent() - Constructor for class io.grpc.channelz.v1.ChannelTraceEvent
- ChannelTraceEvent(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.channelz.v1.ChannelTraceEvent
- ChannelTraceEvent.Builder - Class in io.grpc.channelz.v1
-
A trace event is an interesting thing that happened to a channel or subchannel, such as creation, address resolution, subchannel creation, etc.
- ChannelTraceEvent.ChildRefCase - Enum in io.grpc.channelz.v1
- ChannelTraceEvent.Severity - Enum in io.grpc.channelz.v1
-
The supported severity levels of trace events.
- ChannelTraceEventOrBuilder - Interface in io.grpc.channelz.v1
- ChannelTraceOrBuilder - Interface in io.grpc.channelz.v1
- channelTracer - Variable in class io.grpc.internal.InternalSubchannel
- channelTracer - Variable in class io.grpc.internal.ManagedChannelImpl
- channelTracer - Variable in class io.grpc.internal.OobChannel
- ChannelTracer - Class in io.grpc.internal
-
Tracks a collections of channel tracing events for a channel/subchannel.
- ChannelTracer(InternalLogId, int, long, String) - Constructor for class io.grpc.internal.ChannelTracer
-
Creates a channel tracer and log the creation event of the underlying channel.
- channelType(Class<? extends Channel>) - Method in class io.grpc.netty.NettyChannelBuilder
-
Specifies the channel type to use, by default we use
EpollSocketChannel
if available, otherwise usingNioSocketChannel
. - channelType(Class<? extends Channel>, Class<? extends SocketAddress>) - Method in class io.grpc.netty.NettyChannelBuilder
-
Similar to
NettyChannelBuilder.channelType(Class)
above but allows the caller to specify the socket-type associated with the channelType. - channelType(Class<? extends ServerChannel>) - Method in class io.grpc.netty.NettyServerBuilder
-
Specifies the channel type to use, by default we use
EpollServerSocketChannel
if available, otherwise usingNioServerSocketChannel
. - channelUnused - Variable in class io.grpc.netty.GrpcHttp2ConnectionHandler
- channelUnused - Variable in class io.grpc.netty.NettyServerTransport
- ChannelWrite(Object, ChannelPromise) - Constructor for class io.grpc.netty.WriteBufferingAndExceptionHandler.ChannelWrite
- channelz - Variable in class io.grpc.internal.InternalSubchannel
- channelz - Variable in class io.grpc.internal.ManagedChannelImpl
- channelz - Variable in class io.grpc.internal.ManagedChannelImplBuilder
- channelz - Variable in class io.grpc.internal.OobChannel
- channelz - Variable in class io.grpc.internal.ServerImpl
- channelz - Variable in class io.grpc.internal.ServerImplBuilder
- channelz - Variable in class io.grpc.netty.NettyServer
- channelz - Variable in class io.grpc.protobuf.services.ChannelzService
- ChannelzBaseDescriptorSupplier() - Constructor for class io.grpc.channelz.v1.ChannelzGrpc.ChannelzBaseDescriptorSupplier
- ChannelzBlockingStub(Channel, CallOptions) - Constructor for class io.grpc.channelz.v1.ChannelzGrpc.ChannelzBlockingStub
- ChannelzFileDescriptorSupplier() - Constructor for class io.grpc.channelz.v1.ChannelzGrpc.ChannelzFileDescriptorSupplier
- ChannelzFutureStub(Channel, CallOptions) - Constructor for class io.grpc.channelz.v1.ChannelzGrpc.ChannelzFutureStub
- ChannelzGrpc - Class in io.grpc.channelz.v1
-
Channelz is a service exposed by gRPC servers that provides detailed debug information.
- ChannelzGrpc() - Constructor for class io.grpc.channelz.v1.ChannelzGrpc
- ChannelzGrpc.AsyncService - Interface in io.grpc.channelz.v1
-
Channelz is a service exposed by gRPC servers that provides detailed debug information.
- ChannelzGrpc.ChannelzBaseDescriptorSupplier - Class in io.grpc.channelz.v1
- ChannelzGrpc.ChannelzBlockingStub - Class in io.grpc.channelz.v1
-
A stub to allow clients to do synchronous rpc calls to service Channelz.
- ChannelzGrpc.ChannelzFileDescriptorSupplier - Class in io.grpc.channelz.v1
- ChannelzGrpc.ChannelzFutureStub - Class in io.grpc.channelz.v1
-
A stub to allow clients to do ListenableFuture-style rpc calls to service Channelz.
- ChannelzGrpc.ChannelzImplBase - Class in io.grpc.channelz.v1
-
Base class for the server implementation of the service Channelz.
- ChannelzGrpc.ChannelzMethodDescriptorSupplier - Class in io.grpc.channelz.v1
- ChannelzGrpc.ChannelzStub - Class in io.grpc.channelz.v1
-
A stub to allow clients to do asynchronous rpc calls to service Channelz.
- ChannelzGrpc.MethodHandlers<Req,
Resp> - Class in io.grpc.channelz.v1 - ChannelzImplBase() - Constructor for class io.grpc.channelz.v1.ChannelzGrpc.ChannelzImplBase
- ChannelzMethodDescriptorSupplier(String) - Constructor for class io.grpc.channelz.v1.ChannelzGrpc.ChannelzMethodDescriptorSupplier
- ChannelzProto - Class in io.grpc.channelz.v1
- ChannelzProto() - Constructor for class io.grpc.channelz.v1.ChannelzProto
- ChannelzProtoUtil - Class in io.grpc.protobuf.services
-
A static utility class for turning internal data structures into protos.
- ChannelzProtoUtil() - Constructor for class io.grpc.protobuf.services.ChannelzProtoUtil
- ChannelzService - Class in io.grpc.protobuf.services
-
The channelz service provides stats about a running gRPC process.
- ChannelzService - Class in io.grpc.services
-
Deprecated.
- ChannelzService(int) - Constructor for class io.grpc.services.ChannelzService
-
Deprecated.
- ChannelzService(InternalChannelz, int) - Constructor for class io.grpc.protobuf.services.ChannelzService
- ChannelzStub(Channel, CallOptions) - Constructor for class io.grpc.channelz.v1.ChannelzGrpc.ChannelzStub
- check(HealthCheckRequest) - Method in class io.grpc.health.v1.HealthGrpc.HealthBlockingStub
-
If the requested service is unknown, the call will fail with status NOT_FOUND.
- check(HealthCheckRequest) - Method in class io.grpc.health.v1.HealthGrpc.HealthFutureStub
-
If the requested service is unknown, the call will fail with status NOT_FOUND.
- check(HealthCheckRequest, StreamObserver<HealthCheckResponse>) - Method in interface io.grpc.health.v1.HealthGrpc.AsyncService
-
If the requested service is unknown, the call will fail with status NOT_FOUND.
- check(HealthCheckRequest, StreamObserver<HealthCheckResponse>) - Method in class io.grpc.health.v1.HealthGrpc.HealthStub
-
If the requested service is unknown, the call will fail with status NOT_FOUND.
- check(HealthCheckRequest, StreamObserver<HealthCheckResponse>) - Method in class io.grpc.protobuf.services.HealthServiceImpl
- checkAlpnAvailability() - Static method in class io.grpc.netty.JettyTlsUtil.Java9AlpnUnavailabilityCauseHolder
- checkAuthority(String) - Static method in class io.grpc.internal.GrpcUtil
-
Verify
authority
is valid for use with gRPC. - checkAuthority(String) - Method in class io.grpc.internal.ManagedChannelImplBuilder
-
Verifies the authority is valid.
- checkAvailable() - Static method in class io.grpc.internal.JndiResourceResolverFactory.JndiRecordFetcher
- checkClientTrusted(X509Certificate[], String) - Method in class io.grpc.util.AdvancedTlsX509TrustManager
- checkClientTrusted(X509Certificate[], String, Socket) - Method in class io.grpc.util.AdvancedTlsX509TrustManager
- checkClientTrusted(X509Certificate[], String, SSLEngine) - Method in class io.grpc.util.AdvancedTlsX509TrustManager
- checkDigits(String) - Static method in class io.grpc.protobuf.services.BinlogHelper.FactoryImpl
-
Returns
s
, after verifying it contains only digits. - 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()
. - checkForTermination() - Method in class io.grpc.internal.ServerImpl
-
Notify of complete shutdown if necessary.
- checkJwkEntry(Map<String, ?>, String) - Static method in class io.grpc.internal.SpiffeUtil
- checkKeys(Set<String>, String, String) - Static method in class io.grpc.rls.RlsProtoConverters
- checkListEntryTypes(List<?>) - Static method in class io.grpc.internal.ManagedChannelImplBuilder
- checkListHasNoNulls(List<?>, String) - Static method in class io.grpc.internal.InternalSubchannel
- checkMapEntryTypes(Map<?, ?>) - Static method in class io.grpc.internal.ManagedChannelImplBuilder
- checkNotNull(T, Object) - Static method in class io.grpc.Context
- checkNotNull(T, Object) - Static method in class io.grpc.Deadline
- checkObjectList(List<?>) - Static method in class io.grpc.internal.JsonUtil
-
Casts a list of unchecked JSON values to a list of checked objects in Java type.
- checkReadable(int) - Method in class io.grpc.internal.AbstractReadableBuffer
- checkServerTrusted(X509Certificate[], String) - Method in class io.grpc.util.AdvancedTlsX509TrustManager
- checkServerTrusted(X509Certificate[], String, Socket) - Method in class io.grpc.util.AdvancedTlsX509TrustManager
- checkServerTrusted(X509Certificate[], String, SSLEngine) - Method in class io.grpc.util.AdvancedTlsX509TrustManager
- checkStringList(List<?>) - Static method in class io.grpc.internal.JsonUtil
-
Casts a list of unchecked JSON values to a list of String.
- checkTicker(Deadline) - Method in class io.grpc.Deadline
- checkTrusted(X509Certificate[], String, SSLEngine, Socket, boolean) - Method in class io.grpc.util.AdvancedTlsX509TrustManager
- checkUniqueKey(List<RlsProtoData.NameMatcher>, Set<String>) - Static method in class io.grpc.rls.RlsProtoConverters
- childChannelOptions - Variable in class io.grpc.netty.NettyServer
- childChannelOptions - Variable in class io.grpc.netty.NettyServerBuilder
- childConfig - Variable in class io.grpc.util.GracefulSwitchLoadBalancer.Config
- childConfig - Variable in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig.Builder
- childConfig - Variable in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig
- childFactory - Variable in class io.grpc.util.GracefulSwitchLoadBalancer.Config
- childHelper - Variable in class io.grpc.util.OutlierDetectionLoadBalancer
- ChildHelper(LoadBalancer.Helper) - Constructor for class io.grpc.util.OutlierDetectionLoadBalancer.ChildHelper
- childLbHelperProvider - Variable in class io.grpc.rls.LbPolicyConfiguration.RefCountedChildPolicyWrapperFactory
- childLbResolvedAddressFactory - Variable in class io.grpc.rls.CachingRlsLbClient
- childLbResolvedAddressFactory - Variable in class io.grpc.rls.LbPolicyConfiguration.RefCountedChildPolicyWrapperFactory
- ChildLbResolvedAddressFactory - Class in io.grpc.rls
-
Factory to create
LoadBalancer.ResolvedAddresses
from child load-balancers. - ChildLbResolvedAddressFactory(List<EquivalentAddressGroup>, Attributes) - Constructor for class io.grpc.rls.ChildLbResolvedAddressFactory
- ChildLbState(Object, LoadBalancer.Factory) - Constructor for class io.grpc.util.MultiChildLoadBalancer.ChildLbState
- ChildLbStateHelper() - Constructor for class io.grpc.util.MultiChildLoadBalancer.ChildLbState.ChildLbStateHelper
- childLbStates - Variable in class io.grpc.util.MultiChildLoadBalancer
- childLbStatusListener - Variable in class io.grpc.rls.LbPolicyConfiguration.RefCountedChildPolicyWrapperFactory
- ChildLoadBalancerHelper - Class in io.grpc.rls
-
A delegating
LoadBalancer.Helper
for the child load blanacer. - ChildLoadBalancerHelper(String, LoadBalancer.Helper, SubchannelStateManager, LoadBalancer.SubchannelPicker) - Constructor for class io.grpc.rls.ChildLoadBalancerHelper
- ChildLoadBalancerHelper.ChildLoadBalancerHelperProvider - Class in io.grpc.rls
- ChildLoadBalancerHelperProvider(LoadBalancer.Helper, SubchannelStateManager, LoadBalancer.SubchannelPicker) - Constructor for class io.grpc.rls.ChildLoadBalancerHelper.ChildLoadBalancerHelperProvider
- ChildLoadBalancingPolicy(String, Map<String, Object>, LoadBalancerProvider) - Constructor for class io.grpc.rls.LbPolicyConfiguration.ChildLoadBalancingPolicy
- childPolicy - Variable in class io.grpc.rls.LbPolicyConfiguration.RefCountedChildPolicyWrapperFactory
- childPolicyMap - Variable in class io.grpc.rls.LbPolicyConfiguration.RefCountedChildPolicyWrapperFactory
- ChildPolicyReportingHelper(ChildLoadBalancerHelper.ChildLoadBalancerHelperProvider, LbPolicyConfiguration.ChildLbStatusListener) - Constructor for class io.grpc.rls.LbPolicyConfiguration.ChildPolicyWrapper.ChildPolicyReportingHelper
- childPolicyWrapper - Variable in class io.grpc.rls.LbPolicyConfiguration.RefCountedChildPolicyWrapper
- ChildPolicyWrapper(String, LbPolicyConfiguration.ChildLoadBalancingPolicy, ResolvedAddressFactory, ChildLoadBalancerHelper.ChildLoadBalancerHelperProvider, LbPolicyConfiguration.ChildLbStatusListener) - Constructor for class io.grpc.rls.LbPolicyConfiguration.ChildPolicyWrapper
- childPolicyWrappers - Variable in class io.grpc.rls.CachingRlsLbClient.DataCacheEntry
- childRef_ - Variable in class io.grpc.channelz.v1.ChannelTraceEvent.Builder
- childRef_ - Variable in class io.grpc.channelz.v1.ChannelTraceEvent
- CHILDREF_NOT_SET - Enum constant in enum io.grpc.channelz.v1.ChannelTraceEvent.ChildRefCase
- ChildRefCase(int) - Constructor for enum io.grpc.channelz.v1.ChannelTraceEvent.ChildRefCase
- childRefCase_ - Variable in class io.grpc.channelz.v1.ChannelTraceEvent.Builder
- childRefCase_ - Variable in class io.grpc.channelz.v1.ChannelTraceEvent
- ChoiceChannelCredentials - Class in io.grpc
-
Provides a list of
ChannelCredentials
, where any one may be used. - ChoiceChannelCredentials(List<ChannelCredentials>) - Constructor for class io.grpc.ChoiceChannelCredentials
- ChoiceServerCredentials - Class in io.grpc
-
Provides a list of
ServerCredentials
, where any one may be used. - ChoiceServerCredentials(ServerCredentials...) - Constructor for class io.grpc.ChoiceServerCredentials
- chooseClientAlias(String[], Principal[], Socket) - Method in class io.grpc.util.AdvancedTlsX509KeyManager
- chooseEngineClientAlias(String[], Principal[], SSLEngine) - Method in class io.grpc.util.AdvancedTlsX509KeyManager
- chooseEngineServerAlias(String, Principal[], SSLEngine) - Method in class io.grpc.util.AdvancedTlsX509KeyManager
- chooseServerAlias(String, Principal[], Socket) - Method in class io.grpc.util.AdvancedTlsX509KeyManager
- cipherSuite_ - Variable in class io.grpc.channelz.v1.Security.Tls.Builder
- cipherSuite_ - Variable in class io.grpc.channelz.v1.Security.Tls
- CIPHERSUITE_NOT_SET - Enum constant in enum io.grpc.channelz.v1.Security.Tls.CipherSuiteCase
- CipherSuiteCase(int) - Constructor for enum io.grpc.channelz.v1.Security.Tls.CipherSuiteCase
- cipherSuiteCase_ - Variable in class io.grpc.channelz.v1.Security.Tls.Builder
- cipherSuiteCase_ - Variable in class io.grpc.channelz.v1.Security.Tls
- 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.
- cleanQueue(ReferenceQueue<ManagedChannelOrphanWrapper>) - Static method in class io.grpc.internal.ManagedChannelOrphanWrapper.ManagedChannelReference
- cleanStatus(Status, boolean) - Static method in class io.grpc.inprocess.InProcessTransport
-
Returns a new status with the same code and description.
- cleanup() - Method in class io.grpc.rls.CachingRlsLbClient.BackoffCacheEntry
- cleanup() - Method in class io.grpc.rls.CachingRlsLbClient.CacheEntry
- cleanup() - Method in class io.grpc.rls.CachingRlsLbClient.DataCacheEntry
- cleanUp() - Method in class io.grpc.grpclb.GrpclbState.LbStream
- cleanupExpiredEntries() - Method in class io.grpc.rls.LinkedHashLruCache
-
Returns
true
if any entries were removed. - cleanupExpiredEntries(int, long) - Method in class io.grpc.rls.LinkedHashLruCache
- cleanupExpiredEntries(long) - Method in class io.grpc.rls.LinkedHashLruCache
- clear() - Method in class io.grpc.binarylog.v1.Address.Builder
- clear() - Method in class io.grpc.binarylog.v1.ClientHeader.Builder
- clear() - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
- clear() - Method in class io.grpc.binarylog.v1.Message.Builder
- clear() - Method in class io.grpc.binarylog.v1.Metadata.Builder
- clear() - Method in class io.grpc.binarylog.v1.MetadataEntry.Builder
- clear() - Method in class io.grpc.binarylog.v1.ServerHeader.Builder
- clear() - Method in class io.grpc.binarylog.v1.Trailer.Builder
- clear() - Method in class io.grpc.channelz.v1.Address.Builder
- clear() - Method in class io.grpc.channelz.v1.Address.OtherAddress.Builder
- clear() - Method in class io.grpc.channelz.v1.Address.TcpIpAddress.Builder
- clear() - Method in class io.grpc.channelz.v1.Address.UdsAddress.Builder
- clear() - Method in class io.grpc.channelz.v1.Channel.Builder
- clear() - Method in class io.grpc.channelz.v1.ChannelConnectivityState.Builder
- clear() - Method in class io.grpc.channelz.v1.ChannelData.Builder
- clear() - Method in class io.grpc.channelz.v1.ChannelRef.Builder
- clear() - Method in class io.grpc.channelz.v1.ChannelTrace.Builder
- clear() - Method in class io.grpc.channelz.v1.ChannelTraceEvent.Builder
- clear() - Method in class io.grpc.channelz.v1.GetChannelRequest.Builder
- clear() - Method in class io.grpc.channelz.v1.GetChannelResponse.Builder
- clear() - Method in class io.grpc.channelz.v1.GetServerRequest.Builder
- clear() - Method in class io.grpc.channelz.v1.GetServerResponse.Builder
- clear() - Method in class io.grpc.channelz.v1.GetServerSocketsRequest.Builder
- clear() - Method in class io.grpc.channelz.v1.GetServerSocketsResponse.Builder
- clear() - Method in class io.grpc.channelz.v1.GetServersRequest.Builder
- clear() - Method in class io.grpc.channelz.v1.GetServersResponse.Builder
- clear() - Method in class io.grpc.channelz.v1.GetSocketRequest.Builder
- clear() - Method in class io.grpc.channelz.v1.GetSocketResponse.Builder
- clear() - Method in class io.grpc.channelz.v1.GetSubchannelRequest.Builder
- clear() - Method in class io.grpc.channelz.v1.GetSubchannelResponse.Builder
- clear() - Method in class io.grpc.channelz.v1.GetTopChannelsRequest.Builder
- clear() - Method in class io.grpc.channelz.v1.GetTopChannelsResponse.Builder
- clear() - Method in class io.grpc.channelz.v1.Security.Builder
- clear() - Method in class io.grpc.channelz.v1.Security.OtherSecurity.Builder
- clear() - Method in class io.grpc.channelz.v1.Security.Tls.Builder
- clear() - Method in class io.grpc.channelz.v1.Server.Builder
- clear() - Method in class io.grpc.channelz.v1.ServerData.Builder
- clear() - Method in class io.grpc.channelz.v1.ServerRef.Builder
- clear() - Method in class io.grpc.channelz.v1.Socket.Builder
- clear() - Method in class io.grpc.channelz.v1.SocketData.Builder
- clear() - Method in class io.grpc.channelz.v1.SocketOption.Builder
- clear() - Method in class io.grpc.channelz.v1.SocketOptionLinger.Builder
- clear() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
- clear() - Method in class io.grpc.channelz.v1.SocketOptionTimeout.Builder
- clear() - Method in class io.grpc.channelz.v1.SocketRef.Builder
- clear() - Method in class io.grpc.channelz.v1.Subchannel.Builder
- clear() - Method in class io.grpc.channelz.v1.SubchannelRef.Builder
- clear() - Method in class io.grpc.grpclb.CachedSubchannelPool
- clear() - Method in interface io.grpc.grpclb.SubchannelPool
-
Shuts down all subchannels in the pool immediately.
- clear() - Method in class io.grpc.health.v1.HealthCheckRequest.Builder
- clear() - Method in class io.grpc.health.v1.HealthCheckResponse.Builder
- clear() - Method in class io.grpc.internal.ManagedChannelOrphanWrapper.ManagedChannelReference
-
This clear() is *not* called automatically by the JVM.
- clear() - Method in class io.grpc.lb.v1.ClientStats.Builder
- clear() - Method in class io.grpc.lb.v1.ClientStatsPerToken.Builder
- clear() - Method in class io.grpc.lb.v1.FallbackResponse.Builder
- clear() - Method in class io.grpc.lb.v1.InitialLoadBalanceRequest.Builder
- clear() - Method in class io.grpc.lb.v1.InitialLoadBalanceResponse.Builder
- clear() - Method in class io.grpc.lb.v1.LoadBalanceRequest.Builder
- clear() - Method in class io.grpc.lb.v1.LoadBalanceResponse.Builder
- clear() - Method in class io.grpc.lb.v1.Server.Builder
- clear() - Method in class io.grpc.lb.v1.ServerList.Builder
- clear() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
- clear() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys.Builder
- clear() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Name.Builder
- clear() - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
- clear() - Method in class io.grpc.lookup.v1.NameMatcher.Builder
- clear() - Method in class io.grpc.lookup.v1.RouteLookupClusterSpecifier.Builder
- clear() - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
- clear() - Method in class io.grpc.lookup.v1.RouteLookupRequest.Builder
- clear() - Method in class io.grpc.lookup.v1.RouteLookupResponse.Builder
- clear() - Method in class io.grpc.netty.AbstractHttp2Headers
- clear() - Method in class io.grpc.reflection.v1.ErrorResponse.Builder
- clear() - Method in class io.grpc.reflection.v1.ExtensionNumberResponse.Builder
- clear() - Method in class io.grpc.reflection.v1.ExtensionRequest.Builder
- clear() - Method in class io.grpc.reflection.v1.FileDescriptorResponse.Builder
- clear() - Method in class io.grpc.reflection.v1.ListServiceResponse.Builder
- clear() - Method in class io.grpc.reflection.v1.ServerReflectionRequest.Builder
- clear() - Method in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
- clear() - Method in class io.grpc.reflection.v1.ServiceResponse.Builder
- clear() - Method in class io.grpc.reflection.v1alpha.ErrorResponse.Builder
- clear() - Method in class io.grpc.reflection.v1alpha.ExtensionNumberResponse.Builder
- clear() - Method in class io.grpc.reflection.v1alpha.ExtensionRequest.Builder
- clear() - Method in class io.grpc.reflection.v1alpha.FileDescriptorResponse.Builder
- clear() - Method in class io.grpc.reflection.v1alpha.ListServiceResponse.Builder
- clear() - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest.Builder
- clear() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
- clear() - Method in class io.grpc.reflection.v1alpha.ServiceResponse.Builder
- clearActive() - Method in class io.grpc.channelz.v1.SocketOptionLinger.Builder
-
active maps to `struct linger.l_onoff`
- clearAdditional() - Method in class io.grpc.channelz.v1.SocketOption.Builder
-
Additional data associated with the socket option.
- clearAddress() - Method in class io.grpc.binarylog.v1.Address.Builder
-
string address = 2;
- clearAddress() - Method in class io.grpc.channelz.v1.Address.Builder
- clearAllExtensionNumbersOfType() - Method in class io.grpc.reflection.v1.ServerReflectionRequest.Builder
-
Finds the tag numbers used by all known extensions of the given message type, and appends them to ExtensionNumberResponse in an undefined order.
- clearAllExtensionNumbersOfType() - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest.Builder
-
Finds the tag numbers used by all known extensions of extendee_type, and appends them to ExtensionNumberResponse in an undefined order.
- clearAllExtensionNumbersResponse() - Method in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
-
This message is used to answer all_extension_numbers_of_type requests.
- clearAllExtensionNumbersResponse() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
-
This message is used to answer all_extension_numbers_of_type requst.
- clearApplicationUtilizationMetric() - Method in class io.grpc.services.MetricRecorder
-
Clear the application specific utilization metrics data.
- clearAuthority() - Method in class io.grpc.binarylog.v1.ClientHeader.Builder
-
A single process may be used to run multiple virtual servers with different identities.
- clearBaseTypeName() - Method in class io.grpc.reflection.v1.ExtensionNumberResponse.Builder
-
Full name of the base type, including the package name.
- clearBaseTypeName() - Method in class io.grpc.reflection.v1alpha.ExtensionNumberResponse.Builder
-
Full name of the base type, including the package name.
- clearCacheSizeBytes() - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
Rough indicator of amount of memory to use for the client cache.
- clearCallId() - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
Uniquely identifies a call.
- clearCallsFailed() - Method in class io.grpc.channelz.v1.ChannelData.Builder
-
The number of calls that have completed with a non-OK status
- clearCallsFailed() - Method in class io.grpc.channelz.v1.ServerData.Builder
-
The number of incoming calls that have a completed with a non-OK status
- clearCallsFinishedWithDrop() - Method in class io.grpc.lb.v1.ClientStats.Builder
-
The list of dropped calls.
- clearCallsStarted() - Method in class io.grpc.channelz.v1.ChannelData.Builder
-
The number of calls started on the channel
- clearCallsStarted() - Method in class io.grpc.channelz.v1.ServerData.Builder
-
The number of incoming calls started on the server
- clearCallsSucceeded() - Method in class io.grpc.channelz.v1.ChannelData.Builder
-
The number of calls that have completed with an OK status
- clearCallsSucceeded() - Method in class io.grpc.channelz.v1.ServerData.Builder
-
The number of incoming calls that have completed with an OK status
- clearChannel() - Method in class io.grpc.channelz.v1.GetChannelResponse.Builder
-
The Channel that corresponds to the requested channel_id.
- clearChannel() - Method in class io.grpc.channelz.v1.GetTopChannelsResponse.Builder
-
list of channels that the connection detail service knows about.
- clearChannelId() - Method in class io.grpc.channelz.v1.ChannelRef.Builder
-
The globally unique id for this channel.
- clearChannelId() - Method in class io.grpc.channelz.v1.GetChannelRequest.Builder
-
channel_id is the identifier of the specific channel to get.
- clearChannelRef() - Method in class io.grpc.channelz.v1.Channel.Builder
-
There are no ordering guarantees on the order of channel refs.
- clearChannelRef() - Method in class io.grpc.channelz.v1.ChannelTraceEvent.Builder
-
.grpc.channelz.v1.ChannelRef channel_ref = 4;
- clearChannelRef() - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
There are no ordering guarantees on the order of channel refs.
- clearChildRef() - Method in class io.grpc.channelz.v1.ChannelTraceEvent.Builder
- clearCipherSuite() - Method in class io.grpc.channelz.v1.Security.Tls.Builder
- clearClientHeader() - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
.grpc.binarylog.v1.ClientHeader client_header = 6;
- clearClientStats() - Method in class io.grpc.lb.v1.LoadBalanceRequest.Builder
-
The client stats should be periodically reported to the load balancer based on the duration defined in the InitialLoadBalanceResponse.
- clearClientStatsReportInterval() - Method in class io.grpc.lb.v1.InitialLoadBalanceResponse.Builder
-
This interval defines how often the client should send the client stats to the load balancer.
- clearConstantKeys() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
- clearConstantKeys() - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
- clearContainingType() - Method in class io.grpc.reflection.v1.ExtensionRequest.Builder
-
Fully-qualified type name.
- clearContainingType() - Method in class io.grpc.reflection.v1alpha.ExtensionRequest.Builder
-
Fully-qualified type name.
- clearCpuUtilizationMetric() - Method in class io.grpc.services.MetricRecorder
-
Clear the CPU utilization metrics data.
- clearCreationTimestamp() - Method in class io.grpc.channelz.v1.ChannelTrace.Builder
-
Time that this channel was created.
- clearData() - Method in class io.grpc.binarylog.v1.Message.Builder
-
May be truncated or omitted.
- clearData() - Method in class io.grpc.channelz.v1.Channel.Builder
-
Data specific to this channel.
- clearData() - Method in class io.grpc.channelz.v1.Server.Builder
-
The associated data of the Server.
- clearData() - Method in class io.grpc.channelz.v1.Socket.Builder
-
Data specific to this Socket.
- clearData() - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
Data specific to this channel.
- clearDefaultTarget() - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
This value provides a default target to use if needed.
- clearDescription() - Method in class io.grpc.channelz.v1.ChannelTraceEvent.Builder
-
High level description of the event.
- clearDrop() - Method in class io.grpc.lb.v1.Server.Builder
-
Indicates whether this particular request should be dropped by the client.
- clearDuration() - Method in class io.grpc.channelz.v1.SocketOptionLinger.Builder
-
duration maps to `struct linger.l_linger`
- clearDuration() - Method in class io.grpc.channelz.v1.SocketOptionTimeout.Builder
-
.google.protobuf.Duration duration = 1;
- clearEnd() - Method in class io.grpc.channelz.v1.GetServerSocketsResponse.Builder
-
If set, indicates that the list of sockets is the final list.
- clearEnd() - Method in class io.grpc.channelz.v1.GetServersResponse.Builder
-
If set, indicates that the list of servers is the final list.
- clearEnd() - Method in class io.grpc.channelz.v1.GetTopChannelsResponse.Builder
-
If set, indicates that the list of channels is the final list.
- clearEndpointTracker() - Method in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionSubchannel
- clearEntry() - Method in class io.grpc.binarylog.v1.Metadata.Builder
-
repeated .grpc.binarylog.v1.MetadataEntry entry = 1;
- clearEpsMetric() - Method in class io.grpc.services.MetricRecorder
-
Clear the EPS metrics data.
- clearErrorCode() - Method in class io.grpc.reflection.v1.ErrorResponse.Builder
-
This field uses the error codes defined in grpc::StatusCode.
- clearErrorCode() - Method in class io.grpc.reflection.v1alpha.ErrorResponse.Builder
-
This field uses the error codes defined in grpc::StatusCode.
- clearErrorMessage() - Method in class io.grpc.reflection.v1.ErrorResponse.Builder
-
string error_message = 2;
- clearErrorMessage() - Method in class io.grpc.reflection.v1alpha.ErrorResponse.Builder
-
string error_message = 2;
- clearErrorResponse() - Method in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
-
This message is used when an error occurs.
- clearErrorResponse() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
-
This message is used when an error occurs.
- clearEvents() - Method in class io.grpc.channelz.v1.ChannelTrace.Builder
-
List of events that have occurred on this channel.
- clearExtensionNumber() - Method in class io.grpc.reflection.v1.ExtensionNumberResponse.Builder
-
repeated int32 extension_number = 2;
- clearExtensionNumber() - Method in class io.grpc.reflection.v1.ExtensionRequest.Builder
-
int32 extension_number = 2;
- clearExtensionNumber() - Method in class io.grpc.reflection.v1alpha.ExtensionNumberResponse.Builder
-
repeated int32 extension_number = 2;
- clearExtensionNumber() - Method in class io.grpc.reflection.v1alpha.ExtensionRequest.Builder
-
int32 extension_number = 2;
- clearExtraKeys() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
-
.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys extra_keys = 3;
- clearFallbackResponse() - Method in class io.grpc.lb.v1.LoadBalanceResponse.Builder
-
If this field is set, then the client should eagerly enter fallback mode (even if there are existing, healthy connections to backends).
- clearFileByFilename() - Method in class io.grpc.reflection.v1.ServerReflectionRequest.Builder
-
Find a proto file by the file name.
- clearFileByFilename() - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest.Builder
-
Find a proto file by the file name.
- clearFileContainingExtension() - Method in class io.grpc.reflection.v1.ServerReflectionRequest.Builder
-
Find the proto file which defines an extension extending the given message type with the given field number.
- clearFileContainingExtension() - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest.Builder
-
Find the proto file which defines an extension extending the given message type with the given field number.
- clearFileContainingSymbol() - Method in class io.grpc.reflection.v1.ServerReflectionRequest.Builder
-
Find the proto file that declares the given fully-qualified symbol name.
- clearFileContainingSymbol() - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest.Builder
-
Find the proto file that declares the given fully-qualified symbol name.
- clearFileDescriptorProto() - Method in class io.grpc.reflection.v1.FileDescriptorResponse.Builder
-
Serialized FileDescriptorProto messages.
- clearFileDescriptorProto() - Method in class io.grpc.reflection.v1alpha.FileDescriptorResponse.Builder
-
Serialized FileDescriptorProto messages.
- clearFileDescriptorResponse() - Method in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
-
This message is used to answer file_by_filename, file_containing_symbol, file_containing_extension requests with transitive dependencies.
- clearFileDescriptorResponse() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
-
This message is used to answer file_by_filename, file_containing_symbol, file_containing_extension requests with transitive dependencies.
- clearFilename() - Method in class io.grpc.channelz.v1.Address.UdsAddress.Builder
-
string filename = 1;
- clearGrpcKeybuilders() - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
Unordered specifications for constructing keys for gRPC requests.
- clearHeaderData() - Method in class io.grpc.lookup.v1.RouteLookupResponse.Builder
-
Optional header value to pass along to AFE in the X-Google-RLS-Data header.
- clearHeaders() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
-
Extract keys from all listed headers.
- clearHeaders() - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
-
List of headers to try to match.
- clearHost() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys.Builder
-
string host = 1;
- clearHost() - Method in class io.grpc.reflection.v1.ServerReflectionRequest.Builder
-
string host = 1;
- clearHost() - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest.Builder
-
string host = 1;
- clearHostPatterns() - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
-
host_pattern is an ordered list of host template patterns for the desired value.
- clearHttpKeybuilders() - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
Ordered specifications for constructing keys for HTTP requests.
- clearInitialRequest() - Method in class io.grpc.lb.v1.LoadBalanceRequest.Builder
-
This message should be sent on the first request to the load balancer.
- clearInitialResponse() - Method in class io.grpc.lb.v1.LoadBalanceResponse.Builder
-
This message should be sent on the first response to the client.
- clearInternal() - Method in class io.grpc.internal.ManagedChannelOrphanWrapper.ManagedChannelReference
- clearIpAddress() - Method in class io.grpc.channelz.v1.Address.TcpIpAddress.Builder
-
Either the IPv4 or IPv6 address in bytes.
- clearIpAddress() - Method in class io.grpc.lb.v1.Server.Builder
-
A resolved address for the server, serialized in network-byte-order.
- clearIpPort() - Method in class io.grpc.binarylog.v1.Address.Builder
-
only for TYPE_IPV4 and TYPE_IPV6
- clearKeepAlivesSent() - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The number of keep alives sent.
- clearKey() - Method in class io.grpc.binarylog.v1.MetadataEntry.Builder
-
string key = 1;
- clearKey() - Method in class io.grpc.lookup.v1.NameMatcher.Builder
-
The name that will be used in the RLS key_map to refer to this value.
- clearKeyManagers() - Method in class io.grpc.TlsChannelCredentials.Builder
- clearKeyManagers() - Method in class io.grpc.TlsServerCredentials.Builder
- clearKeyMap() - Method in class io.grpc.lookup.v1.RouteLookupRequest.Builder
- clearLastCallStartedTimestamp() - Method in class io.grpc.channelz.v1.ChannelData.Builder
-
The last time a call was started on the channel.
- clearLastCallStartedTimestamp() - Method in class io.grpc.channelz.v1.ServerData.Builder
-
The last time a call was started on the server.
- clearLastLocalStreamCreatedTimestamp() - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The last time a stream was created by this endpoint.
- clearLastMessageReceivedTimestamp() - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The last time a message was received by this endpoint.
- clearLastMessageSentTimestamp() - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The last time a message was sent by this endpoint.
- clearLastRemoteStreamCreatedTimestamp() - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The last time a stream was created by the remote endpoint.
- clearLength() - Method in class io.grpc.binarylog.v1.Message.Builder
-
Length of the message.
- clearListenSocket() - Method in class io.grpc.channelz.v1.Server.Builder
-
The sockets that the server is listening on.
- clearListServices() - Method in class io.grpc.reflection.v1.ServerReflectionRequest.Builder
-
List the full names of registered services.
- clearListServices() - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest.Builder
-
List the full names of registered services.
- clearListServicesResponse() - Method in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
-
This message is used to answer list_services requests.
- clearListServicesResponse() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
-
This message is used to answer list_services request.
- clearLoadBalanceRequestType() - Method in class io.grpc.lb.v1.LoadBalanceRequest.Builder
- clearLoadBalanceResponseType() - Method in class io.grpc.lb.v1.LoadBalanceResponse.Builder
- clearLoadBalanceToken() - Method in class io.grpc.lb.v1.ClientStatsPerToken.Builder
-
See Server.load_balance_token.
- clearLoadBalanceToken() - Method in class io.grpc.lb.v1.Server.Builder
-
An opaque but printable token for load reporting.
- clearLocal() - Method in class io.grpc.channelz.v1.Socket.Builder
-
The locally bound address.
- clearLocalCertificate() - Method in class io.grpc.channelz.v1.Security.Tls.Builder
-
the certificate used by this endpoint.
- clearLocalFlowControlWindow() - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The amount of window, granted to the local endpoint by the remote endpoint.
- clearLogger() - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
One of the above Logger enum
- clearLookupService() - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
The name of the lookup service as a gRPC URI.
- clearLookupServiceTimeout() - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
Configure a timeout value for lookup service requests.
- clearMaxAge() - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
How long are responses valid for (like HTTP Cache-Control).
- clearMaxResults() - Method in class io.grpc.channelz.v1.GetServerSocketsRequest.Builder
-
If non-zero, the server will return a page of results containing at most this many items.
- clearMaxResults() - Method in class io.grpc.channelz.v1.GetServersRequest.Builder
-
If non-zero, the server will return a page of results containing at most this many items.
- clearMaxResults() - Method in class io.grpc.channelz.v1.GetTopChannelsRequest.Builder
-
If non-zero, the server will return a page of results containing at most this many items.
- clearMemoryUtilizationMetric() - Method in class io.grpc.services.MetricRecorder
-
Clear the memory utilization metrics data.
- clearMessage() - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
Used by EVENT_TYPE_CLIENT_MESSAGE, EVENT_TYPE_SERVER_MESSAGE
- clearMessageRequest() - Method in class io.grpc.reflection.v1.ServerReflectionRequest.Builder
- clearMessageRequest() - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest.Builder
- clearMessageResponse() - Method in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
- clearMessageResponse() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
- clearMessagesReceived() - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The number of grpc messages received on this socket.
- clearMessagesSent() - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The number of grpc messages successfully sent on this socket.
- clearMetadata() - Method in class io.grpc.binarylog.v1.ClientHeader.Builder
-
This contains only the metadata from the application.
- clearMetadata() - Method in class io.grpc.binarylog.v1.ServerHeader.Builder
-
This contains only the metadata from the application.
- clearMetadata() - Method in class io.grpc.binarylog.v1.Trailer.Builder
-
This contains only the metadata from the application.
- clearMethod() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys.Builder
-
string method = 3;
- clearMethod() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Name.Builder
-
string method = 2;
- clearMethodName() - Method in class io.grpc.binarylog.v1.ClientHeader.Builder
-
The name of the RPC method, which looks something like: /<service>/<method> Note the leading "/" character.
- clearModel() - Method in class io.grpc.channelz.v1.Security.Builder
- clearName() - Method in class io.grpc.channelz.v1.Address.OtherAddress.Builder
-
The human readable version of the value.
- clearName() - Method in class io.grpc.channelz.v1.ChannelRef.Builder
-
An optional name associated with the channel.
- clearName() - Method in class io.grpc.channelz.v1.Security.OtherSecurity.Builder
-
The human readable version of the value.
- clearName() - Method in class io.grpc.channelz.v1.ServerRef.Builder
-
An optional name associated with the server.
- clearName() - Method in class io.grpc.channelz.v1.SocketOption.Builder
-
The full name of the socket option.
- clearName() - Method in class io.grpc.channelz.v1.SocketRef.Builder
-
An optional name associated with the socket.
- clearName() - Method in class io.grpc.channelz.v1.SubchannelRef.Builder
-
An optional name associated with the subchannel.
- clearName() - Method in class io.grpc.lb.v1.InitialLoadBalanceRequest.Builder
-
The name of the load balanced service (e.g., service.googleapis.com).
- clearName() - Method in class io.grpc.reflection.v1.ServiceResponse.Builder
-
Full name of a registered service, including its package name.
- clearName() - Method in class io.grpc.reflection.v1alpha.ServiceResponse.Builder
-
Full name of a registered service, including its package name.
- clearNames() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
-
repeated .grpc.lookup.v1.GrpcKeyBuilder.Name names = 1;
- clearNames() - Method in class io.grpc.lookup.v1.NameMatcher.Builder
-
Ordered list of names (headers or query parameter names) that can supply this value; the first one with a non-empty value is used.
- clearNumCalls() - Method in class io.grpc.lb.v1.ClientStatsPerToken.Builder
-
The total number of RPCs that finished associated with the token.
- clearNumCallsFinished() - Method in class io.grpc.lb.v1.ClientStats.Builder
-
The total number of RPCs that finished.
- clearNumCallsFinishedKnownReceived() - Method in class io.grpc.lb.v1.ClientStats.Builder
-
The total number of RPCs that finished and are known to have been received by a server.
- clearNumCallsFinishedWithClientFailedToSend() - Method in class io.grpc.lb.v1.ClientStats.Builder
-
The total number of RPCs that failed to reach a server except dropped RPCs.
- clearNumCallsStarted() - Method in class io.grpc.lb.v1.ClientStats.Builder
-
The total number of RPCs that started.
- clearNumEventsLogged() - Method in class io.grpc.channelz.v1.ChannelTrace.Builder
-
Number of events ever logged in this tracing object.
- clearOnReadyThreshold() - Method in class io.grpc.CallOptions
-
Resets to the default number of bytes that must be queued before the call will leave the 'wait for ready' state.
- clearOption() - Method in class io.grpc.channelz.v1.SocketData.Builder
-
Socket options set on this socket.
- clearOriginalRequest() - Method in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
-
.grpc.reflection.v1.ServerReflectionRequest original_request = 2;
- clearOriginalRequest() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
-
.grpc.reflection.v1alpha.ServerReflectionRequest original_request = 2;
- clearOther() - Method in class io.grpc.channelz.v1.Security.Builder
-
.grpc.channelz.v1.Security.OtherSecurity other = 2;
- clearOtherAddress() - Method in class io.grpc.channelz.v1.Address.Builder
-
.grpc.channelz.v1.Address.OtherAddress other_address = 3;
- clearOtherName() - Method in class io.grpc.channelz.v1.Security.Tls.Builder
-
Some other way to describe the cipher suite if the RFC 4346 name is not available.
- clearPathPatterns() - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
-
path_pattern is an ordered list of path template patterns for the desired value.
- clearPayload() - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
- clearPayloadTruncated() - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
true if payload does not represent the full message or metadata.
- clearPeer() - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
Peer address information, will only be recorded on the first incoming event.
- clearPort() - Method in class io.grpc.channelz.v1.Address.TcpIpAddress.Builder
-
0-64k, or -1 if not appropriate.
- clearPort() - Method in class io.grpc.lb.v1.Server.Builder
-
A resolved port number for the server.
- clearQpsMetric() - Method in class io.grpc.services.MetricRecorder
-
Clear the QPS metrics data.
- clearQueryParameters() - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
-
List of query parameter names to try to match.
- clearReason() - Method in class io.grpc.lookup.v1.RouteLookupRequest.Builder
-
Reason for making this request.
- clearRef() - Method in class io.grpc.channelz.v1.Channel.Builder
-
The identifier for this channel.
- clearRef() - Method in class io.grpc.channelz.v1.Server.Builder
-
The identifier for a Server.
- clearRef() - Method in class io.grpc.channelz.v1.Socket.Builder
-
The identifier for the Socket.
- clearRef() - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
The identifier for this channel.
- clearRemote() - Method in class io.grpc.channelz.v1.Socket.Builder
-
The remote bound address.
- clearRemoteCertificate() - Method in class io.grpc.channelz.v1.Security.Tls.Builder
-
the certificate used by the remote endpoint.
- clearRemoteFlowControlWindow() - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The amount of window, granted to the remote endpoint by the local endpoint.
- clearRemoteName() - Method in class io.grpc.channelz.v1.Socket.Builder
-
Optional, represents the name of the remote endpoint, if different than the original target name.
- clearRequiredMatch() - Method in class io.grpc.lookup.v1.NameMatcher.Builder
-
If true, make this extraction required; the key builder will not match if no value is found.
- clearRouteLookupConfig() - Method in class io.grpc.lookup.v1.RouteLookupClusterSpecifier.Builder
-
The RLS config for this cluster specifier plugin instance.
- clearSafely() - Method in class io.grpc.internal.ManagedChannelOrphanWrapper.ManagedChannelReference
-
Safe to call concurrently.
- clearSecurity() - Method in class io.grpc.channelz.v1.Socket.Builder
-
Security details for this socket.
- clearSequenceIdWithinCall() - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
The entry sequence id for this call.
- clearServer() - Method in class io.grpc.channelz.v1.GetServerResponse.Builder
-
The Server that corresponds to the requested server_id.
- clearServer() - Method in class io.grpc.channelz.v1.GetServersResponse.Builder
-
list of servers that the connection detail service knows about.
- clearServer(InProcessServer) - Method in class io.grpc.inprocess.AnonymousInProcessSocketAddress
- clearServerHeader() - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
.grpc.binarylog.v1.ServerHeader server_header = 7;
- clearServerId() - Method in class io.grpc.channelz.v1.GetServerRequest.Builder
-
server_id is the identifier of the specific server to get.
- clearServerId() - Method in class io.grpc.channelz.v1.GetServerSocketsRequest.Builder
-
int64 server_id = 1;
- clearServerId() - Method in class io.grpc.channelz.v1.ServerRef.Builder
-
A globally unique identifier for this server.
- clearServerList() - Method in class io.grpc.lb.v1.LoadBalanceResponse.Builder
-
Contains the list of servers selected by the load balancer.
- clearServers() - Method in class io.grpc.lb.v1.ServerList.Builder
-
Contains a list of servers selected by the load balancer.
- clearService() - Method in class io.grpc.health.v1.HealthCheckRequest.Builder
-
string service = 1;
- clearService() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys.Builder
-
string service = 2;
- clearService() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Name.Builder
-
string service = 1;
- clearService() - Method in class io.grpc.reflection.v1.ListServiceResponse.Builder
-
The information of each service may be expanded in the future, so we use ServiceResponse message to encapsulate it.
- clearService() - Method in class io.grpc.reflection.v1alpha.ListServiceResponse.Builder
-
The information of each service may be expanded in the future, so we use ServiceResponse message to encapsulate it.
- clearSeverity() - Method in class io.grpc.channelz.v1.ChannelTraceEvent.Builder
-
the severity of the trace event
- clearSocket() - Method in class io.grpc.channelz.v1.GetSocketResponse.Builder
-
The Socket that corresponds to the requested socket_id.
- clearSocketId() - Method in class io.grpc.channelz.v1.GetSocketRequest.Builder
-
socket_id is the identifier of the specific socket to get.
- clearSocketId() - Method in class io.grpc.channelz.v1.SocketRef.Builder
-
The globally unique id for this socket.
- clearSocketRef() - Method in class io.grpc.channelz.v1.Channel.Builder
-
There are no ordering guarantees on the order of sockets.
- clearSocketRef() - Method in class io.grpc.channelz.v1.GetServerSocketsResponse.Builder
-
list of socket refs that the connection detail service knows about.
- clearSocketRef() - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
There are no ordering guarantees on the order of sockets.
- clearStaleAge() - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
After a response has been in the client cache for this amount of time and is re-requested, start an asynchronous RPC to re-validate it.
- clearStaleHeaderData() - Method in class io.grpc.lookup.v1.RouteLookupRequest.Builder
-
For REASON_STALE, the header_data from the stale response, if any.
- clearStandardName() - Method in class io.grpc.channelz.v1.Security.Tls.Builder
-
The cipher suite name in the RFC 4346 format: https://tools.ietf.org/html/rfc4346#appendix-C
- clearStartChannelId() - Method in class io.grpc.channelz.v1.GetTopChannelsRequest.Builder
-
start_channel_id indicates that only channels at or above this id should be included in the results.
- clearStartServerId() - Method in class io.grpc.channelz.v1.GetServersRequest.Builder
-
start_server_id indicates that only servers at or above this id should be included in the results.
- clearStartSocketId() - Method in class io.grpc.channelz.v1.GetServerSocketsRequest.Builder
-
start_socket_id indicates that only sockets at or above this id should be included in the results.
- clearState() - Method in class io.grpc.channelz.v1.ChannelConnectivityState.Builder
-
.grpc.channelz.v1.ChannelConnectivityState.State state = 1;
- clearState() - Method in class io.grpc.channelz.v1.ChannelData.Builder
-
The connectivity state of the channel or subchannel.
- clearStatus() - Method in class io.grpc.health.v1.HealthCheckResponse.Builder
-
.grpc.health.v1.HealthCheckResponse.ServingStatus status = 1;
- clearStatus(String) - Method in class io.grpc.protobuf.services.HealthServiceImpl
- clearStatus(String) - Method in class io.grpc.protobuf.services.HealthStatusManager
-
Clears the health status record of a service.
- clearStatus(String) - Method in class io.grpc.services.HealthStatusManager
-
Deprecated.Clears the health status record of a service.
- clearStatusCode() - Method in class io.grpc.binarylog.v1.Trailer.Builder
-
The gRPC status code.
- clearStatusDetails() - Method in class io.grpc.binarylog.v1.Trailer.Builder
-
The value of the 'grpc-status-details-bin' metadata key.
- clearStatusMessage() - Method in class io.grpc.binarylog.v1.Trailer.Builder
-
An original status message before any transport specific encoding.
- clearStreamsFailed() - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The number of streams that have ended unsuccessfully: On client side, ended without receiving frame with eos bit set; On server side, ended without sending frame with eos bit set.
- clearStreamsStarted() - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The number of streams that have been started.
- clearStreamsSucceeded() - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The number of streams that have ended successfully: On client side, received frame with eos bit set; On server side, sent frame with eos bit set.
- clearSubchannel() - Method in class io.grpc.channelz.v1.GetSubchannelResponse.Builder
-
The Subchannel that corresponds to the requested subchannel_id.
- clearSubchannelId() - Method in class io.grpc.channelz.v1.GetSubchannelRequest.Builder
-
subchannel_id is the identifier of the specific subchannel to get.
- clearSubchannelId() - Method in class io.grpc.channelz.v1.SubchannelRef.Builder
-
The globally unique id for this subchannel.
- clearSubchannelRef() - Method in class io.grpc.channelz.v1.Channel.Builder
-
At most one of 'channel_ref+subchannel_ref' and 'socket' is set.
- clearSubchannelRef() - Method in class io.grpc.channelz.v1.ChannelTraceEvent.Builder
-
.grpc.channelz.v1.SubchannelRef subchannel_ref = 5;
- clearSubchannelRef() - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
At most one of 'channel_ref+subchannel_ref' and 'socket' is set.
- clearSummary() - Method in class io.grpc.channelz.v1.GetSocketRequest.Builder
-
If true, the response will contain only high level information that is inexpensive to obtain.
- clearTarget() - Method in class io.grpc.channelz.v1.ChannelData.Builder
-
The target this channel originally tried to connect to.
- clearTargets() - Method in class io.grpc.lookup.v1.RouteLookupResponse.Builder
-
Prioritized list (best one first) of addressable entities to use for routing, using syntax requested by the request target_type.
- clearTargetType() - Method in class io.grpc.lookup.v1.RouteLookupRequest.Builder
-
Target type allows the client to specify what kind of target format it would like from RLS to allow it to find the regional server, e.g.
- clearTcpiAdvmss() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_advmss = 28;
- clearTcpiAto() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_ato = 10;
- clearTcpiBackoff() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_backoff = 5;
- clearTcpiCaState() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_ca_state = 2;
- clearTcpiFackets() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_fackets = 17;
- clearTcpiLastAckRecv() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_last_ack_recv = 21;
- clearTcpiLastAckSent() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_last_ack_sent = 19;
- clearTcpiLastDataRecv() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_last_data_recv = 20;
- clearTcpiLastDataSent() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_last_data_sent = 18;
- clearTcpiLost() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_lost = 15;
- clearTcpiOptions() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_options = 6;
- clearTcpipAddress() - Method in class io.grpc.channelz.v1.Address.Builder
-
.grpc.channelz.v1.Address.TcpIpAddress tcpip_address = 1;
- clearTcpiPmtu() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_pmtu = 22;
- clearTcpiProbes() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_probes = 4;
- clearTcpiRcvMss() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_rcv_mss = 12;
- clearTcpiRcvSsthresh() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_rcv_ssthresh = 23;
- clearTcpiRcvWscale() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_rcv_wscale = 8;
- clearTcpiReordering() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_reordering = 29;
- clearTcpiRetrans() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_retrans = 16;
- clearTcpiRetransmits() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_retransmits = 3;
- clearTcpiRto() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_rto = 9;
- clearTcpiRtt() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_rtt = 24;
- clearTcpiRttvar() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_rttvar = 25;
- clearTcpiSacked() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_sacked = 14;
- clearTcpiSndCwnd() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_snd_cwnd = 27;
- clearTcpiSndMss() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_snd_mss = 11;
- clearTcpiSndSsthresh() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_snd_ssthresh = 26;
- clearTcpiSndWscale() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_snd_wscale = 7;
- clearTcpiState() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_state = 1;
- clearTcpiUnacked() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_unacked = 13;
- clearTimeout() - Method in class io.grpc.binarylog.v1.ClientHeader.Builder
-
the RPC timeout
- clearTimestamp() - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
The timestamp of the binary log message
- clearTimestamp() - Method in class io.grpc.channelz.v1.ChannelTraceEvent.Builder
-
When this event occurred.
- clearTimestamp() - Method in class io.grpc.lb.v1.ClientStats.Builder
-
The timestamp of generating the report.
- clearTls() - Method in class io.grpc.channelz.v1.Security.Builder
-
.grpc.channelz.v1.Security.Tls tls = 1;
- clearTrace() - Method in class io.grpc.channelz.v1.ChannelData.Builder
-
A trace of recent events on the channel.
- clearTrace() - Method in class io.grpc.channelz.v1.ServerData.Builder
-
A trace of recent events on the server.
- clearTrailer() - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
.grpc.binarylog.v1.Trailer trailer = 9;
- clearTrustManagers() - Method in class io.grpc.TlsChannelCredentials.Builder
- clearTrustManagers() - Method in class io.grpc.TlsServerCredentials.Builder
- clearType() - Method in class io.grpc.binarylog.v1.Address.Builder
-
.grpc.binarylog.v1.Address.Type type = 1;
- clearType() - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
.grpc.binarylog.v1.GrpcLogEntry.EventType type = 4;
- clearUdsAddress() - Method in class io.grpc.channelz.v1.Address.Builder
-
.grpc.channelz.v1.Address.UdsAddress uds_address = 2;
- clearValidHost() - Method in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
-
string valid_host = 1;
- clearValidHost() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
-
string valid_host = 1;
- clearValidTargets() - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
This is a list of all the possible targets that can be returned by the lookup service.
- clearValue() - Method in class io.grpc.binarylog.v1.MetadataEntry.Builder
-
bytes value = 2;
- clearValue() - Method in class io.grpc.channelz.v1.Address.OtherAddress.Builder
-
The actual address message.
- clearValue() - Method in class io.grpc.channelz.v1.Security.OtherSecurity.Builder
-
The actual security details message.
- clearValue() - Method in class io.grpc.channelz.v1.SocketOption.Builder
-
The human readable value of this socket option.
- CLIENT_HEADER - Enum constant in enum io.grpc.binarylog.v1.GrpcLogEntry.PayloadCase
- CLIENT_HEADER_FIELD_NUMBER - Static variable in class io.grpc.binarylog.v1.GrpcLogEntry
- CLIENT_STATS - Enum constant in enum io.grpc.lb.v1.LoadBalanceRequest.LoadBalanceRequestTypeCase
- CLIENT_STATS_FIELD_NUMBER - Static variable in class io.grpc.lb.v1.LoadBalanceRequest
- CLIENT_STATS_REPORT_INTERVAL_FIELD_NUMBER - Static variable in class io.grpc.lb.v1.InitialLoadBalanceResponse
- CLIENT_STREAMING - Enum constant in enum io.grpc.MethodDescriptor.MethodType
-
Zero or more request messages with one response message.
- clientAuth - Variable in class io.grpc.TlsServerCredentials.Builder
- clientAuth - Variable in class io.grpc.TlsServerCredentials
- clientAuth(TlsServerCredentials.ClientAuth) - Method in class io.grpc.TlsServerCredentials.Builder
-
Indicates whether the server should expect a client's identity.
- ClientAuth() - Constructor for enum io.grpc.TlsServerCredentials.ClientAuth
- 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.
- ClientCallImpl<ReqT,
RespT> - Class in io.grpc.internal -
Implementation of
ClientCall
. - ClientCallImpl(MethodDescriptor<ReqT, RespT>, Executor, CallOptions, ClientCallImpl.ClientStreamProvider, ScheduledExecutorService, CallTracer, InternalConfigSelector) - Constructor for class io.grpc.internal.ClientCallImpl
- ClientCallImpl.CancellationHandler - Class in io.grpc.internal
- ClientCallImpl.ClientStreamListenerImpl - Class in io.grpc.internal
- ClientCallImpl.ClientStreamProvider - Interface in io.grpc.internal
-
Provider of
ClientStream
s. - clientCallImplChannel - Variable in class io.grpc.internal.ManagedChannelImpl.RealChannel
- ClientCalls - Class in io.grpc.stub
-
Utility functions for processing different call idioms.
- ClientCalls() - Constructor for class io.grpc.stub.ClientCalls
- ClientCalls.BlockingResponseStream<T> - Class in io.grpc.stub
-
Convert events on a
ClientCall.Listener
into a blockingIterator
. - ClientCalls.BlockingResponseStream.QueuingListener - Class in io.grpc.stub
- ClientCalls.CallToStreamObserverAdapter<ReqT> - Class in io.grpc.stub
- ClientCalls.GrpcFuture<RespT> - Class in io.grpc.stub
- ClientCalls.StartableListener<T> - Class in io.grpc.stub
- ClientCalls.StreamObserverToCallListenerAdapter<ReqT,
RespT> - Class in io.grpc.stub - ClientCalls.StubType - Enum in io.grpc.stub
- ClientCalls.ThreadlessExecutor - Class in io.grpc.stub
- ClientCalls.UnaryStreamToFuture<RespT> - Class in io.grpc.stub
-
Completes a
ClientCalls.GrpcFuture
usingStreamObserver
events. - ClientCallStreamObserver<ReqT> - Class in io.grpc.stub
-
A refinement of
CallStreamObserver
that allows for lower-level interaction with client calls. - ClientCallStreamObserver() - Constructor for class io.grpc.stub.ClientCallStreamObserver
- clientCancelled(Status) - Method in class io.grpc.inprocess.InProcessTransport.InProcessStream.InProcessServerStream
- ClientHeader - Class in io.grpc.binarylog.v1
-
Protobuf type
grpc.binarylog.v1.ClientHeader
- ClientHeader() - Constructor for class io.grpc.binarylog.v1.ClientHeader
- ClientHeader(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.binarylog.v1.ClientHeader
- ClientHeader.Builder - Class in io.grpc.binarylog.v1
-
Protobuf type
grpc.binarylog.v1.ClientHeader
- clientHeaderBuilder_ - Variable in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
- ClientHeaderOrBuilder - Interface in io.grpc.binarylog.v1
- clientInboundHeaders(Metadata) - Method in class io.grpc.internal.StatsTraceContext
- clientInboundTrailers(Metadata) - 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
-
Utility methods for working with
ClientInterceptor
s. - ClientInterceptors() - Constructor for class io.grpc.ClientInterceptors
- ClientInterceptors.CheckedForwardingClientCall<ReqT,
RespT> - Class in io.grpc -
A
ForwardingClientCall
that delivers exceptions from its start logic to the call listener. - ClientInterceptors.InterceptorChannel - Class in io.grpc
- ClientKeepAlivePinger(ConnectionClientTransport) - Constructor for class io.grpc.internal.KeepAliveManager.ClientKeepAlivePinger
- clientMaxInboundMetadataSize - Variable in class io.grpc.inprocess.InProcessTransport
- clientNotifyStatus - Variable in class io.grpc.inprocess.InProcessTransport.InProcessStream.InProcessServerStream
- clientNotifyTrailers - Variable in class io.grpc.inprocess.InProcessTransport.InProcessStream.InProcessServerStream
- clientOutboundHeaders() - Method in class io.grpc.internal.StatsTraceContext
- clientReceiveQueue - Variable in class io.grpc.inprocess.InProcessTransport.InProcessStream.InProcessServerStream
- clientRequested - Variable in class io.grpc.inprocess.InProcessTransport.InProcessStream.InProcessServerStream
- clientRequested(int) - Method in class io.grpc.inprocess.InProcessTransport.InProcessStream.InProcessServerStream
-
Client requested more messages.
- clientRequestHeaders(byte[][], AsciiString, AsciiString, AsciiString, AsciiString, AsciiString) - Static method in class io.grpc.netty.GrpcHttp2OutboundHeaders
- ClientResponseObserver<ReqT,
RespT> - Interface in io.grpc.stub -
Specialization of
StreamObserver
implemented by clients in order to interact with the advanced features of a call such as flow-control. - clientSendsOneMessage() - Method in enum io.grpc.MethodDescriptor.MethodType
-
Returns
true
forUNARY
andSERVER_STREAMING
, which do not permit the client to stream. - ClientStats - Class in io.grpc.lb.v1
-
Contains client level statistics that are useful to load balancing.
- ClientStats() - Constructor for class io.grpc.lb.v1.ClientStats
- ClientStats(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.lb.v1.ClientStats
- ClientStats.Builder - Class in io.grpc.lb.v1
-
Contains client level statistics that are useful to load balancing.
- clientStatsBuilder_ - Variable in class io.grpc.lb.v1.LoadBalanceRequest.Builder
- ClientStatsOrBuilder - Interface in io.grpc.lb.v1
- ClientStatsPerToken - Class in io.grpc.lb.v1
-
Contains the number of calls finished for a particular load balance token.
- ClientStatsPerToken() - Constructor for class io.grpc.lb.v1.ClientStatsPerToken
- ClientStatsPerToken(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.lb.v1.ClientStatsPerToken
- ClientStatsPerToken.Builder - Class in io.grpc.lb.v1
-
Contains the number of calls finished for a particular load balance token.
- ClientStatsPerTokenOrBuilder - Interface in io.grpc.lb.v1
- clientStatsReportInterval_ - Variable in class io.grpc.lb.v1.InitialLoadBalanceResponse.Builder
- clientStatsReportInterval_ - Variable in class io.grpc.lb.v1.InitialLoadBalanceResponse
- clientStatsReportIntervalBuilder_ - Variable in class io.grpc.lb.v1.InitialLoadBalanceResponse.Builder
- clientStream - Variable in class io.grpc.inprocess.InProcessTransport.InProcessStream
- clientStream(Http2Stream) - Method in class io.grpc.netty.NettyClientHandler
-
Gets the client stream associated to the given HTTP/2 stream object.
- ClientStream - Interface in io.grpc.internal
-
Extension of
Stream
to support client-side termination semantics. - clientStreamListener - Variable in class io.grpc.inprocess.InProcessTransport.InProcessStream.InProcessServerStream
- 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.
- ClientStreamListenerImpl(ClientCall.Listener<RespT>) - Constructor for class io.grpc.internal.ClientCallImpl.ClientStreamListenerImpl
- clientStreamProvider - Variable in class io.grpc.internal.ClientCallImpl
- ClientStreamTracer - Class in io.grpc
-
StreamTracer
for the client-side. - ClientStreamTracer() - Constructor for class io.grpc.ClientStreamTracer
- ClientStreamTracer.Factory - Class in io.grpc
-
Factory class for
ClientStreamTracer
. - ClientStreamTracer.StreamInfo - Class in io.grpc
-
Information about a stream.
- ClientStreamTracer.StreamInfo.Builder - Class in io.grpc
-
Builds
ClientStreamTracer.StreamInfo
objects. - clientTlsHandler(ChannelHandler, SslContext, String, ChannelLogger) - Static method in class io.grpc.netty.InternalProtocolNegotiators
- ClientTlsHandler(ChannelHandler, SslContext, String, Executor, ChannelLogger, Optional<Runnable>) - Constructor for class io.grpc.netty.ProtocolNegotiators.ClientTlsHandler
- ClientTlsProtocolNegotiator(SslContext, ObjectPool<? extends Executor>, Optional<Runnable>) - Constructor for class io.grpc.netty.ProtocolNegotiators.ClientTlsProtocolNegotiator
- ClientTransport - Interface in io.grpc.internal
-
The client-side transport typically encapsulating a single connection to a remote server.
- ClientTransport.PingCallback - Interface in io.grpc.internal
-
A callback that is invoked when the acknowledgement to a
ClientTransport.ping(io.grpc.internal.ClientTransport.PingCallback, java.util.concurrent.Executor)
is received. - ClientTransportFactory - Interface in io.grpc.internal
-
Pre-configured factory for creating
ConnectionClientTransport
instances. - ClientTransportFactory.ClientTransportOptions - Class in io.grpc.internal
- ClientTransportFactory.SwapChannelCredentialsResult - Class in io.grpc.internal
- clientTransportFactoryBuilder - Variable in class io.grpc.internal.ManagedChannelImplBuilder
- ClientTransportFilter - Class in io.grpc
-
Listens on the client transport life-cycle events.
- ClientTransportFilter() - Constructor for class io.grpc.ClientTransportFilter
- ClientTransportLifecycleManager - Class in io.grpc.netty
-
Maintainer of transport lifecycle status.
- ClientTransportLifecycleManager(ManagedClientTransport.Listener) - Constructor for class io.grpc.netty.ClientTransportLifecycleManager
- clientTransportListener - Variable in class io.grpc.inprocess.InProcessTransport
- ClientTransportOptions() - Constructor for class io.grpc.internal.ClientTransportFactory.ClientTransportOptions
- clientTransportServersBuilder - Variable in class io.grpc.internal.ServerImplBuilder
- clientWriteQueue - Variable in class io.grpc.netty.NettyClientHandler
- close() - Method in class io.grpc.Context.CancellableContext
-
Cleans up this object by calling
cancel(null)
. - close() - Method in class io.grpc.inprocess.InProcessChannelBuilder.InProcessClientTransportFactory
- close() - Method in class io.grpc.internal.AbstractClientStream.GetFramer
-
Closes, with flush.
- close() - Method in class io.grpc.internal.AbstractReadableBuffer
- close() - Method in class io.grpc.internal.ApplicationThreadDeframer
- close() - Method in class io.grpc.internal.ApplicationThreadDeframer.CloseableInitializingMessageProducer
- close() - Method in class io.grpc.internal.CallCredentialsApplyingTransportFactory
- 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.GzipInflatingBuffer
- 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 class io.grpc.internal.MigratingThreadDeframer
- close() - Method in class io.grpc.internal.MigratingThreadDeframer.DeframeMessageProducer
- close() - Method in interface io.grpc.internal.ReadableBuffer
-
Closes this buffer and releases any resources.
- close() - Method in class io.grpc.internal.ReadableBuffers.BufferInputStream
- close() - Method in interface io.grpc.MetricRecorder.Registration
-
Unregister.
- close() - Method in class io.grpc.netty.InternalProtocolNegotiator.ProtocolNegotiatorAdapter
- close() - Method in class io.grpc.netty.NettyChannelBuilder.NettyTransportFactory
- close() - Method in class io.grpc.netty.NettyReadableBuffer
-
If the first call to close, calls
ReferenceCounted.release()
to release the internal Netty buffer. - close() - Method in interface io.grpc.netty.ProtocolNegotiator
-
Releases resources held by this negotiator.
- close() - Method in class io.grpc.netty.ProtocolNegotiators.ClientTlsProtocolNegotiator
- close() - Method in class io.grpc.netty.ProtocolNegotiators.PlaintextProtocolNegotiator
- close() - Method in class io.grpc.netty.ProtocolNegotiators.PlaintextUpgradeProtocolNegotiator
- close() - Method in class io.grpc.protobuf.services.BinaryLogProvider
- close() - Method in class io.grpc.protobuf.services.BinaryLogProviderImpl
- close() - Method in class io.grpc.protobuf.services.TempFileSink
- close() - Method in class io.grpc.rls.CachingRlsLbClient
-
Performs any pending maintenance operations needed by the cache.
- close() - Method in class io.grpc.rls.CachingRlsLbClient.RlsPicker
- close() - Method in class io.grpc.rls.LinkedHashLruCache
- close() - Method in interface io.grpc.rls.LruCache
-
Closes underlying resources.
- close() - Method in interface io.grpc.util.AdvancedTlsX509KeyManager.Closeable
- close() - Method in interface io.grpc.util.AdvancedTlsX509TrustManager.Closeable
- close(Status, Metadata) - Method in class io.grpc.inprocess.InProcessTransport.InProcessStream.InProcessServerStream
- close(Status, Metadata) - Method in class io.grpc.internal.AbstractServerStream
- close(Status, Metadata) - Method in class io.grpc.internal.ServerCallImpl
- close(Status, Metadata) - Method in interface io.grpc.internal.ServerStream
-
Closes the stream for both reading and writing.
- close(Status, Metadata) - Method in class io.grpc.PartialForwardingServerCall
- close(Status, Metadata) - Method in class io.grpc.ServerCall
-
Close the call with the provided status.
- close(Status, Metadata) - Method in class io.grpc.stub.MetadataUtils.MetadataAttachingServerInterceptor.MetadataAttachingServerCall
- close(Status, Metadata) - Method in class io.grpc.util.TransmitStatusRuntimeExceptionInterceptor.SerializingServerCall
- close(ChannelHandlerContext, ChannelPromise) - Method in class io.grpc.netty.NettyClientHandler
- close(ChannelHandlerContext, ChannelPromise) - Method in class io.grpc.netty.NettyServerHandler
- close(ChannelHandlerContext, ChannelPromise) - Method in class io.grpc.netty.WriteBufferingAndExceptionHandler
-
If we are still performing protocol negotiation, then this will propagate failures to all buffered writes.
- close(EventLoopGroup) - Method in class io.grpc.netty.Utils.DefaultEventLoopGroupResource
- close(Exception) - Method in class io.grpc.grpclb.GrpclbState.LbStream
- close(T) - Method in interface io.grpc.internal.SharedResourceHolder.Resource
-
Destroy the given instance.
- closeable - Variable in class io.grpc.internal.ApplicationThreadDeframer.CloseableInitializingMessageProducer
- CloseableInitializingMessageProducer(Runnable, Closeable) - Constructor for class io.grpc.internal.ApplicationThreadDeframer.CloseableInitializingMessageProducer
- closeAfterSend - Variable in class io.grpc.protobuf.services.ProtoReflectionServiceV1.ProtoReflectionStreamObserver
- closeCalled - Variable in class io.grpc.internal.ServerCallImpl
- closeCalled - Variable in class io.grpc.util.TransmitStatusRuntimeExceptionInterceptor.SerializingServerCall
- closed - Variable in class io.grpc.grpclb.GrpclbState.LbStream
- closed - Variable in class io.grpc.inprocess.InProcessChannelBuilder.InProcessClientTransportFactory
- closed - Variable in class io.grpc.inprocess.InProcessTransport.InProcessStream.InProcessClientStream
- closed - Variable in class io.grpc.inprocess.InProcessTransport.InProcessStream.InProcessServerStream
- closed - Variable in class io.grpc.internal.AbstractClientStream.GetFramer
- closed - Variable in class io.grpc.internal.GzipInflatingBuffer
- closed - Variable in class io.grpc.internal.MessageFramer
- closed - Variable in class io.grpc.internal.RetriableStream.Substream
- closed - Variable in class io.grpc.internal.SquelchLateMessagesAvailableDeframerListener
- closed - Variable in class io.grpc.internal.StatsTraceContext
- closed - Variable in class io.grpc.netty.NettyChannelBuilder.NettyTransportFactory
- closed - Variable in class io.grpc.netty.NettyReadableBuffer
- closed - Variable in class io.grpc.protobuf.services.TempFileSink
- closed(Status) - Method in class io.grpc.internal.ServerCallImpl.ServerStreamListenerImpl
- closed(Status) - Method in class io.grpc.internal.ServerImpl.JumpToApplicationThreadServerStreamListener
- closed(Status) - Method in class io.grpc.internal.ServerImpl.NoopListener
- closed(Status) - Method in interface io.grpc.internal.ServerStreamListener
-
Called when the stream is fully closed.
- closed(Status, ClientStreamListener.RpcProgress, Metadata) - Method in class io.grpc.internal.ClientCallImpl.ClientStreamListenerImpl
- closed(Status, ClientStreamListener.RpcProgress, Metadata) - Method in interface io.grpc.internal.ClientStreamListener
-
Called when the stream is fully closed.
- closed(Status, ClientStreamListener.RpcProgress, Metadata) - Method in class io.grpc.internal.DelayedStream.DelayedStreamListener
- closed(Status, ClientStreamListener.RpcProgress, Metadata) - Method in class io.grpc.internal.ForwardingClientStreamListener
- closed(Status, ClientStreamListener.RpcProgress, Metadata) - Method in class io.grpc.internal.RetriableStream.Sublistener
- closeDeframer(boolean) - Method in class io.grpc.internal.AbstractStream.TransportState
-
Closes the deframer and frees any resources.
- closedInternal(Status) - Method in class io.grpc.internal.ServerCallImpl.ServerStreamListenerImpl
- closedInternal(Status) - Method in class io.grpc.internal.ServerImpl.JumpToApplicationThreadServerStreamListener
- closedInternal(Status, ClientStreamListener.RpcProgress, Metadata) - Method in class io.grpc.internal.ClientCallImpl.ClientStreamListenerImpl
- closedStatus - Variable in class io.grpc.internal.AbstractServerStream.TransportState
-
The status that the application used to close this stream.
- closedSubstreamsInsight - Variable in class io.grpc.internal.RetriableStream
- closeInternal(Status, Metadata) - Method in class io.grpc.internal.ServerCallImpl
- closeListener(Status) - Method in class io.grpc.internal.AbstractServerStream.TransportState
-
Closes the listener if not previously closed and frees resources.
- closeListener(Status, ClientStreamListener.RpcProgress, Metadata) - Method in class io.grpc.internal.AbstractClientStream.TransportState
-
Closes the listener if not previously closed.
- CloseListenerRunnable(ClientCall.Listener<RespT>, Status) - Constructor for class io.grpc.internal.DelayedClientCall.CloseListenerRunnable
- closeObserver(ClientCall.Listener<RespT>, Status, Metadata) - Method in class io.grpc.internal.ClientCallImpl
- closeQuietly() - Method in class io.grpc.protobuf.services.TempFileSink
- closeQuietly(StreamListener.MessageProducer) - Static method in class io.grpc.internal.GrpcUtil
-
Quietly closes all messages in MessageProducer.
- closeQuietly(Closeable) - Static method in class io.grpc.internal.GrpcUtil
-
Closes a Closeable, ignoring IOExceptions.
- closeStreamWhenDone(ChannelPromise, Http2Stream) - Method in class io.grpc.netty.NettyServerHandler
- closeThenThrow(DirContext, NamingException) - Static method in class io.grpc.internal.JndiResourceResolverFactory.JndiRecordFetcher
- closeThenThrow(NamingEnumeration<?>, NamingException) - Static method in class io.grpc.internal.JndiResourceResolverFactory.JndiRecordFetcher
- closeWhenComplete - Variable in class io.grpc.internal.MessageDeframer
- 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
- closeWhenComplete() - Method in class io.grpc.internal.MigratingThreadDeframer
- code - Variable in enum io.grpc.internal.GrpcUtil.Http2Error
- code - Variable in class io.grpc.Status
- code() - Method in enum io.grpc.internal.GrpcUtil.Http2Error
-
Gets the code for this error used on the wire.
- Code(int) - Constructor for enum io.grpc.Status.Code
- CODE_KEY - Static variable in class io.grpc.InternalStatus
-
Key to bind status code to trailing metadata.
- CODE_KEY - Static variable in class io.grpc.Status
-
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.
- codeMap - Static variable in enum io.grpc.internal.GrpcUtil.Http2Error
- CollisionLeaf(K[], V[]) - Constructor for class io.grpc.PersistentHashArrayMappedTrie.CollisionLeaf
- CollisionLeaf(K, V, K, V) - Constructor for class io.grpc.PersistentHashArrayMappedTrie.CollisionLeaf
- combine(PersistentHashArrayMappedTrie.Node<K, V>, int, PersistentHashArrayMappedTrie.Node<K, V>, int, int) - Static method in class io.grpc.PersistentHashArrayMappedTrie.CompressedIndex
- CombiningMetadataApplier(CallCredentials.MetadataApplier, Metadata) - Constructor for class io.grpc.CompositeCallCredentials.CombiningMetadataApplier
- commit(RetriableStream.Substream) - Method in class io.grpc.internal.RetriableStream
- commitAndRun(RetriableStream.Substream) - Method in class io.grpc.internal.RetriableStream
-
Calls commit() and if successful runs the post commit task.
- committed(RetriableStream.Substream) - Method in class io.grpc.internal.RetriableStream.State
- commitToSink(boolean, boolean) - Method in class io.grpc.internal.MessageFramer
- compareNanos(long, long) - Static method in class io.grpc.internal.KeepAliveEnforcer
-
Positive when time1 is greater; negative when time2 is greater; 0 when equal.
- compareTo(Deadline) - Method in class io.grpc.Deadline
- 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.
- complete() - Method in class io.grpc.servlet.AsyncServletOutputStreamWriter
-
Called from application thread.
- complete() - Method in class io.grpc.servlet.jakarta.AsyncServletOutputStreamWriter
-
Called from application thread.
- completeAction - Variable in class io.grpc.servlet.AsyncServletOutputStreamWriter
- completeAction - Variable in class io.grpc.servlet.jakarta.AsyncServletOutputStreamWriter
- completed - Variable in class io.grpc.internal.Http2Ping
-
False until the operation completes, either successfully (other side sent acknowledgement) or unsuccessfully.
- completed - Variable in class io.grpc.stub.ClientCalls.CallToStreamObserverAdapter
- completed - Variable in class io.grpc.stub.ServerCalls.ServerCallStreamObserverImpl
- completedConnectivityAttempt - Variable in class io.grpc.internal.PickFirstLeafLoadBalancer.SubchannelData
- completeQueuedTasks() - Method in class io.grpc.internal.SerializeReentrantCallsDirectExecutor
- composeMinSize - Variable in class io.grpc.netty.NettyAdaptiveCumulator
- CompositeCallCredentials - Class in io.grpc
-
Uses multiple
CallCredentials
as if they were one. - CompositeCallCredentials(CallCredentials, CallCredentials) - Constructor for class io.grpc.CompositeCallCredentials
- CompositeCallCredentials.CombiningMetadataApplier - Class in io.grpc
- CompositeCallCredentials.WrappingMetadataApplier - Class in io.grpc
- CompositeChannelCredentials - Class in io.grpc
-
ChannelCredentials
which use per-RPCCallCredentials
. - CompositeChannelCredentials(ChannelCredentials, CallCredentials) - Constructor for class io.grpc.CompositeChannelCredentials
- CompositeReadableBuffer - Class in io.grpc.internal
-
A
ReadableBuffer
that is composed of 0 or moreReadableBuffer
s. - CompositeReadableBuffer() - Constructor for class io.grpc.internal.CompositeReadableBuffer
- CompositeReadableBuffer(int) - Constructor for class io.grpc.internal.CompositeReadableBuffer
- CompositeReadableBuffer.NoThrowReadOperation<T> - Interface in io.grpc.internal
- CompositeReadableBuffer.ReadOperation<T> - Interface in io.grpc.internal
-
A simple read operation to perform on a single
ReadableBuffer
. - 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.
- COMPRESSED - Static variable in class io.grpc.internal.MessageFramer
- COMPRESSED_FLAG_MASK - Static variable in class io.grpc.internal.MessageDeframer
- compressedFlag - Variable in class io.grpc.internal.MessageDeframer
- compressedIndex(int) - Method in class io.grpc.PersistentHashArrayMappedTrie.CompressedIndex
- CompressedIndex(int, PersistentHashArrayMappedTrie.Node<K, V>[], int) - Constructor for class io.grpc.PersistentHashArrayMappedTrie.CompressedIndex
- COMPRESSION_ERROR - Enum constant in enum io.grpc.internal.GrpcUtil.Http2Error
- compressLongestRunOfZeroes(int[]) - Static method in class io.grpc.protobuf.services.InetAddressUtil
- compressor - Variable in class io.grpc.internal.MessageFramer
- compressor - Variable in class io.grpc.internal.ServerCallImpl
- Compressor - Interface in io.grpc
-
Represents a message compressor.
- compressorName - Variable in class io.grpc.CallOptions.Builder
- compressorName - Variable in class io.grpc.CallOptions
- compressorRegistry - Variable in class io.grpc.internal.ClientCallImpl
- compressorRegistry - Variable in class io.grpc.internal.ManagedChannelImpl
- compressorRegistry - Variable in class io.grpc.internal.ManagedChannelImplBuilder
- compressorRegistry - Variable in class io.grpc.internal.ServerCallImpl
- compressorRegistry - Variable in class io.grpc.internal.ServerImpl
- compressorRegistry - Variable in class io.grpc.internal.ServerImplBuilder
- compressorRegistry(CompressorRegistry) - Method in class io.grpc.ForwardingChannelBuilder
- compressorRegistry(CompressorRegistry) - Method in class io.grpc.ForwardingChannelBuilder2
- compressorRegistry(CompressorRegistry) - Method in class io.grpc.ForwardingServerBuilder
- compressorRegistry(CompressorRegistry) - Method in class io.grpc.internal.ManagedChannelImplBuilder
- compressorRegistry(CompressorRegistry) - Method in class io.grpc.internal.ServerImplBuilder
- 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.
- CompressorRegistry - Class in io.grpc
-
Encloses classes related to the compression and decompression of messages.
- CompressorRegistry(Compressor...) - Constructor for class io.grpc.CompressorRegistry
- compressors - Variable in class io.grpc.CompressorRegistry
- concludedState - Variable in class io.grpc.internal.PickFirstLeafLoadBalancer
- concludedState - Variable in class io.grpc.protobuf.services.HealthCheckingLoadBalancerFactory.HealthCheckState
- config - Variable in class io.grpc.grpclb.GrpclbLoadBalancer
- config - Variable in class io.grpc.grpclb.GrpclbState
- config - Variable in class io.grpc.internal.DnsNameResolver.InternalResolutionResult
- config - Variable in class io.grpc.internal.ManagedChannelServiceConfig.ServiceConfigConvertedSelector
- config - Variable in class io.grpc.internal.ServiceConfigUtil.PolicySelection
- config - Variable in class io.grpc.InternalConfigSelector.Result.Builder
- config - Variable in class io.grpc.InternalConfigSelector.Result
- config - Variable in class io.grpc.NameResolver.ConfigOrError
- config - Variable in class io.grpc.util.OutlierDetectionLoadBalancer.DetectionTimer
- config - Variable in class io.grpc.util.OutlierDetectionLoadBalancer.EndpointTracker
- config - Variable in class io.grpc.util.OutlierDetectionLoadBalancer.FailurePercentageOutlierEjectionAlgorithm
- config - Variable in class io.grpc.util.OutlierDetectionLoadBalancer.SuccessRateOutlierEjectionAlgorithm
- Config(LoadBalancer.Factory, Object) - Constructor for class io.grpc.util.GracefulSwitchLoadBalancer.Config
- configFrozen - Variable in class io.grpc.ConfiguratorRegistry
- ConfigOrError(Status) - Constructor for class io.grpc.NameResolver.ConfigOrError
- ConfigOrError(Object) - Constructor for class io.grpc.NameResolver.ConfigOrError
- ConfigSelectingClientCall(InternalConfigSelector, Channel, Executor, MethodDescriptor<ReqT, RespT>, CallOptions) - Constructor for class io.grpc.internal.ManagedChannelImpl.ConfigSelectingClientCall
- configSelector - Variable in class io.grpc.internal.ManagedChannelImpl.ConfigSelectingClientCall
- configSelector - Variable in class io.grpc.internal.ManagedChannelImpl.RealChannel
- configSelector - Variable in class io.grpc.internal.SubchannelChannel
- Configurator - Interface in io.grpc
-
Provides hooks for modifying gRPC channels and servers during their construction.
- ConfiguratorRegistry - Class in io.grpc
-
A registry for
Configurator
instances. - ConfiguratorRegistry() - Constructor for class io.grpc.ConfiguratorRegistry
- configurators - Variable in class io.grpc.ConfiguratorRegistry
- configure(SslContextBuilder) - Static method in class io.grpc.netty.GrpcSslContexts
-
Set ciphers and APN appropriate for gRPC.
- configure(SslContextBuilder, SslProvider) - Static method in class io.grpc.netty.GrpcSslContexts
-
Set ciphers and APN appropriate for gRPC.
- configure(SslContextBuilder, Provider) - Static method in class io.grpc.netty.GrpcSslContexts
-
Set ciphers and APN appropriate for gRPC.
- configureChannelBuilder(ManagedChannelBuilder<?>) - Method in interface io.grpc.Configurator
-
Allows implementations to modify the channel builder.
- configureChannelBuilder(ManagedChannelBuilder<?>) - Static method in class io.grpc.InternalConfiguratorRegistry
- configureServerBuilder(ServerBuilder<?>) - Method in interface io.grpc.Configurator
-
Allows implementations to modify the server builder.
- configureServerBuilder(ServerBuilder<?>) - Static method in class io.grpc.InternalConfiguratorRegistry
- connect(ChannelHandlerContext, SocketAddress, SocketAddress, ChannelPromise) - Method in class io.grpc.netty.WriteBufferingAndExceptionHandler
-
Connect failures do not show up as
WriteBufferingAndExceptionHandler.channelInactive(io.netty.channel.ChannelHandlerContext)
orWriteBufferingAndExceptionHandler.exceptionCaught(io.netty.channel.ChannelHandlerContext, java.lang.Throwable)
, so it needs to be watched. - CONNECT_ERROR - Enum constant in enum io.grpc.internal.GrpcUtil.Http2Error
- connectedAddressAttributes - Variable in class io.grpc.internal.InternalSubchannel
- CONNECTING - Enum constant in enum io.grpc.channelz.v1.ChannelConnectivityState.State
-
CONNECTING = 2;
- CONNECTING - Enum constant in enum io.grpc.ConnectivityState
-
The channel is trying to establish a connection and is waiting to make progress on one of the steps involved in name resolution, TCP connection establishment or TLS handshake.
- CONNECTING_VALUE - Static variable in enum io.grpc.channelz.v1.ChannelConnectivityState.State
-
CONNECTING = 2;
- connectingTimer - Variable in class io.grpc.internal.InternalSubchannel
-
Timer monitoring duration since entering CONNECTING state.
- CONNECTION_DELAY_INTERVAL_MS - Static variable in class io.grpc.internal.PickFirstLeafLoadBalancer
- ConnectionClientTransport - Interface in io.grpc.internal
-
A
ManagedClientTransport
that is based on a connection. - connectionError - Variable in class io.grpc.netty.NettyServerHandler
- connectionError() - Method in class io.grpc.netty.NettyServerHandler
- connectionLog - Static variable in class io.grpc.netty.NettyServerTransport
- connectionRequested - Variable in class io.grpc.grpclb.GrpclbState.IdleSubchannelEntry
- connectionRequested - Variable in class io.grpc.internal.PickFirstLeafLoadBalancer.RequestConnectionPicker
- connectionRequested - Variable in class io.grpc.internal.PickFirstLoadBalancer.RequestConnectionPicker
- connectionStream - Variable in class io.grpc.netty.Utils.FlowControlReader
- ConnectivityState - Enum in io.grpc
-
The connectivity states.
- ConnectivityState() - Constructor for enum io.grpc.ConnectivityState
- ConnectivityStateInfo - Class in io.grpc
-
A tuple of a
ConnectivityState
and its associatedStatus
. - ConnectivityStateInfo(ConnectivityState, Status) - Constructor for class io.grpc.ConnectivityStateInfo
- ConnectivityStateManager - Class in io.grpc.internal
-
Manages connectivity states of the channel.
- ConnectivityStateManager() - Constructor for class io.grpc.internal.ConnectivityStateManager
- ConnectivityStateManager.Listener - Class in io.grpc.internal
- connectProxiedSocketAddr - Variable in class io.grpc.internal.ClientTransportFactory.ClientTransportOptions
- ConscryptHolder() - Constructor for class io.grpc.netty.GrpcSslContexts.ConscryptHolder
- ConscryptLoader - Class in io.grpc.internal
-
Utility to load dynamically Conscrypt when it is available.
- ConscryptLoader() - Constructor for class io.grpc.internal.ConscryptLoader
- CONSTANT_KEYS_FIELD_NUMBER - Static variable in class io.grpc.lookup.v1.GrpcKeyBuilder
- CONSTANT_KEYS_FIELD_NUMBER - Static variable in class io.grpc.lookup.v1.HttpKeyBuilder
- constantKeys - Variable in class io.grpc.rls.AutoValue_RlsProtoData_GrpcKeyBuilder
- constantKeys() - Method in class io.grpc.rls.AutoValue_RlsProtoData_GrpcKeyBuilder
- constantKeys() - Method in class io.grpc.rls.RlsProtoData.GrpcKeyBuilder
- constantKeys_ - Variable in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
- constantKeys_ - Variable in class io.grpc.lookup.v1.GrpcKeyBuilder
- constantKeys_ - Variable in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
- constantKeys_ - Variable in class io.grpc.lookup.v1.HttpKeyBuilder
- ConstantKeysDefaultEntryHolder() - Constructor for class io.grpc.lookup.v1.GrpcKeyBuilder.ConstantKeysDefaultEntryHolder
- ConstantKeysDefaultEntryHolder() - Constructor for class io.grpc.lookup.v1.HttpKeyBuilder.ConstantKeysDefaultEntryHolder
- CONTAINING_TYPE_FIELD_NUMBER - Static variable in class io.grpc.reflection.v1.ExtensionRequest
- CONTAINING_TYPE_FIELD_NUMBER - Static variable in class io.grpc.reflection.v1alpha.ExtensionRequest
- containingType_ - Variable in class io.grpc.reflection.v1.ExtensionRequest.Builder
- containingType_ - Variable in class io.grpc.reflection.v1.ExtensionRequest
- containingType_ - Variable in class io.grpc.reflection.v1alpha.ExtensionRequest.Builder
- containingType_ - Variable in class io.grpc.reflection.v1alpha.ExtensionRequest
- contains(CharSequence) - Method in class io.grpc.netty.AbstractHttp2Headers
- contains(CharSequence) - Method in class io.grpc.netty.GrpcHttp2HeadersUtils.GrpcHttp2InboundHeaders
- contains(CharSequence, CharSequence) - Method in class io.grpc.netty.AbstractHttp2Headers
- contains(CharSequence, CharSequence, boolean) - Method in class io.grpc.netty.AbstractHttp2Headers
- contains(Map<Long, T>, InternalLogId) - Static method in class io.grpc.InternalChannelz
- containsBoolean(CharSequence, boolean) - Method in class io.grpc.netty.AbstractHttp2Headers
- containsByte(CharSequence, byte) - Method in class io.grpc.netty.AbstractHttp2Headers
- containsChar(CharSequence, char) - Method in class io.grpc.netty.AbstractHttp2Headers
- containsClientSocket(InternalLogId) - Method in class io.grpc.InternalChannelz
- containsConstantKeys(String) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
-
You can optionally set one or more specific key/value pairs to be added to the key_map.
- containsConstantKeys(String) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder
-
You can optionally set one or more specific key/value pairs to be added to the key_map.
- containsConstantKeys(String) - Method in interface io.grpc.lookup.v1.GrpcKeyBuilderOrBuilder
-
You can optionally set one or more specific key/value pairs to be added to the key_map.
- containsConstantKeys(String) - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
-
You can optionally set one or more specific key/value pairs to be added to the key_map.
- containsConstantKeys(String) - Method in class io.grpc.lookup.v1.HttpKeyBuilder
-
You can optionally set one or more specific key/value pairs to be added to the key_map.
- containsConstantKeys(String) - Method in interface io.grpc.lookup.v1.HttpKeyBuilderOrBuilder
-
You can optionally set one or more specific key/value pairs to be added to the key_map.
- containsDouble(CharSequence, double) - Method in class io.grpc.netty.AbstractHttp2Headers
- containsFloat(CharSequence, float) - Method in class io.grpc.netty.AbstractHttp2Headers
- containsInt(CharSequence, int) - Method in class io.grpc.netty.AbstractHttp2Headers
- containsKey(Metadata.Key<?>) - Method in class io.grpc.Metadata
-
Returns true if a value is defined for the given key.
- containsKeyMap(String) - Method in class io.grpc.lookup.v1.RouteLookupRequest.Builder
-
Map of key values extracted via key builders for the gRPC or HTTP request.
- containsKeyMap(String) - Method in class io.grpc.lookup.v1.RouteLookupRequest
-
Map of key values extracted via key builders for the gRPC or HTTP request.
- containsKeyMap(String) - Method in interface io.grpc.lookup.v1.RouteLookupRequestOrBuilder
-
Map of key values extracted via key builders for the gRPC or HTTP request.
- containsLong(CharSequence, long) - Method in class io.grpc.netty.AbstractHttp2Headers
- containsObject(CharSequence, Object) - Method in class io.grpc.netty.AbstractHttp2Headers
- containsServer(InternalLogId) - Method in class io.grpc.InternalChannelz
- containsShort(CharSequence, short) - Method in class io.grpc.netty.AbstractHttp2Headers
- containsSubchannel(InternalLogId) - Method in class io.grpc.InternalChannelz
- containsSubchannel(OutlierDetectionLoadBalancer.OutlierDetectionSubchannel) - Method in class io.grpc.util.OutlierDetectionLoadBalancer.EndpointTracker
- containsTimeMillis(CharSequence, long) - Method in class io.grpc.netty.AbstractHttp2Headers
- CONTENT_ACCEPT_ENCODING - Static variable in class io.grpc.internal.GrpcUtil
-
The accepted content-encodings that can be used to compress the full gRPC stream.
- CONTENT_ACCEPT_ENCODING_KEY - Static variable in class io.grpc.internal.GrpcUtil
-
Metadata.Key
for the stream's accepted content encoding header. - CONTENT_ENCODING - Static variable in class io.grpc.internal.GrpcUtil
-
The content-encoding used to compress the full gRPC stream.
- CONTENT_ENCODING_KEY - Static variable in class io.grpc.internal.GrpcUtil
-
Metadata.Key
for the stream's content encoding header. - CONTENT_LENGTH_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_GRPC - Static variable in class io.grpc.netty.Utils
- CONTENT_TYPE_HEADER - Static variable in class io.grpc.netty.Utils
- CONTENT_TYPE_KEY - Static variable in class io.grpc.internal.GrpcUtil
-
Metadata.Key
for the Content-Type request/response header. - context - Variable in class io.grpc.CompositeCallCredentials.WrappingMetadataApplier
- context - Variable in class io.grpc.Context.ExecutableListener
- context - Variable in class io.grpc.Contexts.ContextualizedServerCallListener
- context - Variable in class io.grpc.grpclb.GrpclbLoadBalancer
- context - Variable in class io.grpc.grpclb.GrpclbState
- context - Variable in class io.grpc.internal.ClientCallImpl
- context - Variable in class io.grpc.internal.ContextRunnable
- context - Variable in class io.grpc.internal.DelayedClientCall
- context - Variable in class io.grpc.internal.DelayedClientTransport.PendingStream
- context - Variable in class io.grpc.internal.ManagedChannelImpl.ConfigSelectingClientCall
- context - Variable in class io.grpc.internal.ManagedChannelImpl.RealChannel.PendingCall
- context - Variable in class io.grpc.internal.ServerCallImpl
- context - Variable in class io.grpc.internal.ServerCallImpl.ServerStreamListenerImpl
- context - Variable in class io.grpc.internal.ServerImpl.ContextCloser
- context - Variable in class io.grpc.internal.ServerImpl.JumpToApplicationThreadServerStreamListener
- Context - Class in io.grpc
-
A context propagation mechanism which can carry scoped-values across API boundaries and between threads.
- Context() - Constructor for class io.grpc.Context
-
Construct for
Context.ROOT
. - Context(Context, PersistentHashArrayMappedTrie.Node<Context.Key<?>, Object>) - Constructor for class io.grpc.Context
-
Construct a context that cannot be cancelled but will cascade cancellation from its parent if it is cancellable.
- Context(PersistentHashArrayMappedTrie.Node<Context.Key<?>, Object>, int) - Constructor for class io.grpc.Context
-
Construct a context that cannot be cancelled and will not cascade cancellation from its parent.
- CONTEXT_DEPTH_WARN_THRESH - Static variable in class io.grpc.Context
- CONTEXT_KEY - Static variable in class io.grpc.services.CallMetricRecorder
- CONTEXT_KEY - Static variable in class io.grpc.services.InternalCallMetricRecorder
- 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.CanIgnoreReturnValue - Annotation Type in io.grpc
- Context.CheckReturnValue - Annotation Type in io.grpc
- Context.DirectExecutor - Enum in io.grpc
- Context.ExecutableListener - Class in io.grpc
-
Stores listener and executor pair.
- Context.Key<T> - Class in io.grpc
-
Key for indexing values stored in a context.
- Context.LazyStorage - Class in io.grpc
- Context.Storage - Class in io.grpc
-
Defines the mechanisms for attaching and detaching the "current" context.
- ContextCloser(Context.CancellableContext, Throwable) - Constructor for class io.grpc.internal.ServerImpl.ContextCloser
- contextIsDeadlineSource - Variable in class io.grpc.internal.ClientCallImpl.CancellationHandler
- ContextRunnable - Class in io.grpc.internal
-
Utility base implementation of
Runnable
that performs the same function asContext.wrap(Runnable)
without requiring the construction of an additional object. - ContextRunnable(Context) - Constructor for class io.grpc.internal.ContextRunnable
- Contexts - Class in io.grpc
-
Utility methods for working with
Context
s in GRPC. - Contexts() - Constructor for class io.grpc.Contexts
- Contexts.ContextualizedServerCallListener<ReqT> - Class in io.grpc
-
Implementation of
ForwardingServerCallListener
that attaches a context before dispatching calls to the delegate and detaches them after the call completes. - ContextualizedServerCallListener(ServerCall.Listener<ReqT>, Context) - Constructor for class io.grpc.Contexts.ContextualizedServerCallListener
- convert(Map<String, ?>) - Static method in class io.grpc.rls.RlsProtoConverters.GrpcKeyBuilderConverter
- convertClientHeaders(Metadata, AsciiString, AsciiString, AsciiString, AsciiString, AsciiString) - Static method in class io.grpc.netty.Utils
- convertHeaders(Http2Headers) - Static method in class io.grpc.netty.Utils
- convertHeadersToArray(Http2Headers) - Static method in class io.grpc.netty.Utils
- convertRlsServerStatus(Status, String) - Static method in class io.grpc.rls.CachingRlsLbClient
-
Convert the status to UNAVAILABLE and enhance the error message.
- convertServerHeaders(Metadata) - Static method in class io.grpc.netty.Utils
- convertTrailers(Metadata, boolean) - Static method in class io.grpc.netty.Utils
- convertTrailers(Http2Headers) - Static method in class io.grpc.netty.Utils
- copy(InputStream, OutputStream) - Static method in class io.grpc.protobuf.lite.ProtoLiteUtils
-
Copies the data from input stream to output stream.
- copy(InputStream, OutputStream) - Static method in class io.grpc.protobuf.services.BinaryLogProvider.IoUtils
-
Copies the data from input stream to output stream.
- copyCustomOptions(Object[][]) - Method in class io.grpc.LoadBalancer.CreateSubchannelArgs.Builder
- copyWithFlowControl(Iterable<V>, CallStreamObserver<V>) - Static method in class io.grpc.stub.StreamObservers
-
Deprecated.Copy the values of an
Iterable
to the targetCallStreamObserver
while properly accounting for outbound flow-control. - copyWithFlowControl(Iterator<V>, CallStreamObserver<V>) - Static method in class io.grpc.stub.StreamObservers
-
Deprecated.Copy the values of an
Iterator
to the targetCallStreamObserver
while properly accounting for outbound flow-control. - count - Variable in class io.grpc.internal.MessageDeframer.SizeEnforcingInputStream
- count - Variable in class io.grpc.rls.AdaptiveThrottler.TimeBasedAccumulator.Slot
- counter - Variable in class io.grpc.internal.AtomicLongCounter
- counter - Static variable in class io.grpc.protobuf.services.BinaryLogProviderImpl
- covertAll(List<Map<String, ?>>) - Static method in class io.grpc.rls.RlsProtoConverters.GrpcKeyBuilderConverter
- cpuUtilization - Variable in class io.grpc.services.MetricRecorder
- cpuUtilization - Variable in class io.grpc.services.MetricReport
- cpuUtilizationMetric - Variable in class io.grpc.services.CallMetricRecorder
- crc - Variable in class io.grpc.internal.GzipInflatingBuffer
- create() - Static method in class io.grpc.InsecureChannelCredentials
- create() - Static method in class io.grpc.InsecureServerCredentials
- create() - Method in interface io.grpc.internal.CallTracer.Factory
- create() - Static method in class io.grpc.internal.LongCounterFactory
-
Creates a LongCounter.
- 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() - Static method in class io.grpc.netty.InsecureFromHttp1ChannelCredentials
-
Creates an insecure credential that will upgrade from HTTP/1 to HTTP/2.
- create() - Method in class io.grpc.netty.Utils.DefaultEventLoopGroupResource
- create() - Static method in class io.grpc.TlsChannelCredentials
-
Use TLS with its defaults.
- create(ImmutableList<RlsProtoData.GrpcKeyBuilder.Name>, ImmutableList<RlsProtoData.NameMatcher>, RlsProtoData.ExtraKeys, ImmutableMap<String, String>) - Static method in class io.grpc.rls.RlsProtoData.GrpcKeyBuilder
- create(ImmutableList<String>, String) - Static method in class io.grpc.rls.RlsProtoData.RouteLookupResponse
- create(ImmutableMap<String, String>) - Static method in class io.grpc.rls.RlsProtoData.RouteLookupRequest
- create(ChannelCredentials...) - Static method in class io.grpc.ChoiceChannelCredentials
-
Constructs with the provided
creds
as options, with preferred credentials first. - create(ChannelCredentials, CallCredentials) - Static method in class io.grpc.CompositeChannelCredentials
- create(GrpclbState.Mode) - Static method in class io.grpc.grpclb.GrpclbConfig
- create(GrpclbState.Mode, String, long) - Static method in class io.grpc.grpclb.GrpclbConfig
- create(Metadata.Key<T>, T) - Static method in class io.grpc.Metadata.LazyValue
- create(MethodDescriptor.MethodType, String, MethodDescriptor.Marshaller<RequestT>, MethodDescriptor.Marshaller<ResponseT>) - Static method in class io.grpc.MethodDescriptor
-
Deprecated.
- create(MethodDescriptor<ReqT, RespT>, ServerCallHandler<ReqT, RespT>) - Static method in class io.grpc.ServerMethodDefinition
-
Create a new instance.
- create(InternalProtocolNegotiator.ClientFactory) - Static method in class io.grpc.netty.InternalNettyChannelCredentials
-
Creates a
ChannelCredentials
that will use the providednegotiator
. - create(InternalProtocolNegotiator.ProtocolNegotiator) - Static method in class io.grpc.netty.InternalNettyServerCredentials
-
Creates a
ServerCredentials
that will use the providednegotiator
. - create(InternalProtocolNegotiator.ServerFactory) - Static method in class io.grpc.netty.InternalNettyServerCredentials
-
Creates a
ServerCredentials
that will use the providednegotiator
. - create(ProtocolNegotiator.ClientFactory) - Static method in class io.grpc.netty.NettyChannelCredentials
- create(ProtocolNegotiator.ServerFactory) - Static method in class io.grpc.netty.NettyServerCredentials
- create(ServerCredentials...) - Static method in class io.grpc.ChoiceServerCredentials
-
Constructs with the provided
creds
as options, with preferred credentials first. - create(ServerInterceptor, ServerCallHandler<ReqT, RespT>) - Static method in class io.grpc.ServerInterceptors.InterceptCallHandler
- create(ServerStreamTracer.ServerCallInfo<ReqT, RespT>) - Static method in class io.grpc.ServerStreamTracer.ReadOnlyServerCall
-
Deprecated.
- create(SslContext) - Static method in class io.grpc.netty.NettySslContextChannelCredentials
-
Create a credential using Netty's SslContext as configuration.
- create(SslContext) - Static method in class io.grpc.netty.NettySslContextServerCredentials
-
Create a credential using Netty's SslContext as configuration.
- create(File, File) - Static method in class io.grpc.TlsServerCredentials
-
Creates an instance using provided certificate chain and private key.
- create(InputStream, InputStream) - Static method in class io.grpc.TlsServerCredentials
-
Creates an instance using provided certificate chain and private key.
- create(Object) - Method in class io.grpc.rls.ChildLbResolvedAddressFactory
- create(Object) - Method in interface io.grpc.rls.ResolvedAddressFactory
-
Creates ResolvedAddress with given childLbConfig.
- create(String) - Static method in class io.grpc.Attributes.Key
-
Factory method for creating instances of
Attributes.Key
. - create(String) - Static method in class io.grpc.CallOptions.Key
-
Factory method for creating instances of
CallOptions.Key
. - create(String) - Static method in class io.grpc.LoadBalancer.CreateSubchannelArgs.Key
-
Factory method for creating instances of
LoadBalancer.CreateSubchannelArgs.Key
. - create(String) - Static method in class io.grpc.netty.InternalGracefulServerCloseCommand
- create(String, long, TimeUnit) - Static method in class io.grpc.netty.InternalGracefulServerCloseCommand
- create(String, ImmutableList<String>) - Static method in class io.grpc.rls.RlsProtoData.NameMatcher
- create(String, String) - Static method in class io.grpc.rls.RlsProtoData.GrpcKeyBuilder.Name
- create(String, String, Metadata) - Method in class io.grpc.rls.RlsRequestFactory
-
Creates a
RlsProtoData.RouteLookupRequest
for given request's metadata. - create(String, String, String) - Static method in class io.grpc.rls.RlsProtoData.ExtraKeys
- create(String, List<Map<String, ?>>) - Static method in class io.grpc.rls.LbPolicyConfiguration.ChildLoadBalancingPolicy
-
Creates ChildLoadBalancingPolicy.
- createBackOffEntry(RlsProtoData.RouteLookupRequest, Status, BackoffPolicy) - Method in class io.grpc.rls.CachingRlsLbClient
- createBinaryLog() - Static method in class io.grpc.protobuf.services.BinaryLogs
-
Creates a binary log that writes to a temp file.
- createBinaryLog(BinaryLogSink) - Static method in class io.grpc.protobuf.services.BinaryLogs
-
Deprecated.
- createBinaryLog(BinaryLogSink, String) - Static method in class io.grpc.protobuf.services.BinaryLogs
-
Creates a binary log with a custom
BinaryLogSink
for receiving the logged data, and a config string as defined by A16-binary-logging. - createBinaryLog(BinaryLogSink, String) - Static method in class io.grpc.protobuf.services.BinlogHelper.FactoryImpl
-
Returns a binlog with the correct header and message limits or
null
if the input is malformed. - createByteBufAllocator(boolean) - Static method in class io.grpc.netty.Utils
- createChildAddressesMap(LoadBalancer.ResolvedAddresses) - Method in class io.grpc.util.MultiChildLoadBalancer
-
Override to utilize parsing of the policy configuration or alternative helper/lb generation.
- createChildHelper() - Method in class io.grpc.util.MultiChildLoadBalancer.ChildLbState
- createChildLbState(Object) - Method in class io.grpc.util.MultiChildLoadBalancer
-
Override to create an instance of a subclass.
- createChildLbState(Object) - Method in class io.grpc.util.RoundRobinLoadBalancer
- createContext(Metadata, StatsTraceContext) - Method in class io.grpc.internal.ServerImpl.ServerTransportListenerImpl
- createDataEntry(RlsProtoData.RouteLookupRequest, RlsProtoData.RouteLookupResponse) - Method in class io.grpc.rls.CachingRlsLbClient
- createDelegateTrustManager(KeyStore) - Static method in class io.grpc.util.AdvancedTlsX509TrustManager
- createEpollEventLoopGroup(int, ThreadFactory) - Static method in class io.grpc.netty.Utils
- createForHardCoded(Class<T>, Class<?>) - Static method in class io.grpc.ServiceProviders
- createHandler(ServerTransportListener, ChannelPromise) - Method in class io.grpc.netty.NettyServerTransport
-
Creates the Netty handler to be used in the channel pipeline.
- createHeaders(StreamIdHolder, Http2Headers) - Static method in class io.grpc.netty.SendResponseHeadersCommand
- createKeyBuilderTable(RlsProtoData.RouteLookupConfig) - Static method in class io.grpc.rls.RlsRequestFactory
- createLoadBalancingPolicyConfig(LoadBalancer.Factory, Object) - Static method in class io.grpc.util.GracefulSwitchLoadBalancer
-
Directly create a config to pass to GracefulSwitch.
- createMessageProto(byte[], int) - Static method in class io.grpc.protobuf.services.BinlogHelper
- createMetadataProto(Metadata, int) - Static method in class io.grpc.protobuf.services.BinlogHelper
- createMetricReport(double, double, double, double, double, Map<String, Double>, Map<String, Double>, Map<String, Double>) - Static method in class io.grpc.services.InternalCallMetricRecorder
- createNewSubchannel(SocketAddress, Attributes) - Method in class io.grpc.internal.PickFirstLeafLoadBalancer
- createOobChannel(EquivalentAddressGroup, String) - Method in class io.grpc.internal.ManagedChannelImpl.LbHelperImpl
- 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
- createOobChannel(List<EquivalentAddressGroup>, String) - Method in class io.grpc.internal.ManagedChannelImpl.LbHelperImpl
- createOobChannel(List<EquivalentAddressGroup>, String) - Method in class io.grpc.LoadBalancer.Helper
-
Accept a list of EAG for multiple authorities: https://github.com/grpc/grpc-java/issues/4618
- createOobChannel(List<EquivalentAddressGroup>, String) - Method in class io.grpc.util.ForwardingLoadBalancerHelper
- createOrGet(String) - Method in class io.grpc.rls.LbPolicyConfiguration.RefCountedChildPolicyWrapperFactory
- createOrGet(List<String>) - Method in class io.grpc.rls.LbPolicyConfiguration.RefCountedChildPolicyWrapperFactory
- createPendingEntry(RlsProtoData.RouteLookupRequest, ListenableFuture<RlsProtoData.RouteLookupResponse>, BackoffPolicy) - Method in class io.grpc.rls.CachingRlsLbClient
- createPendingStream() - Method in class io.grpc.ClientStreamTracer
-
Name resolution is completed and the connection starts getting established.
- createPendingStream() - Method in class io.grpc.internal.ForwardingClientStreamTracer
- createPendingStream() - Method in class io.grpc.util.ForwardingClientStreamTracer
- createPendingStream(LoadBalancer.PickSubchannelArgs, ClientStreamTracer[]) - Method in class io.grpc.internal.DelayedClientTransport
-
Caller must call
syncContext.drain()
outside of lock because this method may schedule tasks on syncContext. - createProtocolNegotiatorByType(NegotiationType, SslContext, ObjectPool<? extends Executor>) - Static method in class io.grpc.netty.NettyChannelBuilder
- createReadyPicker(Collection<MultiChildLoadBalancer.ChildLbState>) - Method in class io.grpc.util.RoundRobinLoadBalancer
- createRealStream(ClientTransport) - Method in class io.grpc.internal.DelayedClientTransport.PendingStream
-
Runnable may be null.
- createRequestHeaders(Metadata, List<RlsProtoData.NameMatcher>) - Method in class io.grpc.rls.RlsRequestFactory
- createResolvingOobChannel(String) - Method in class io.grpc.LoadBalancer.Helper
-
Creates an out-of-band channel for LoadBalancer's own RPC needs, e.g., talking to an external load-balancer service, that is specified by a target string.
- createResolvingOobChannel(String) - Method in class io.grpc.util.ForwardingLoadBalancerHelper
- createResolvingOobChannelBuilder(String) - Method in class io.grpc.internal.ManagedChannelImpl.LbHelperImpl
-
Deprecated.
- createResolvingOobChannelBuilder(String) - Method in class io.grpc.LoadBalancer.Helper
-
Deprecated.
- createResolvingOobChannelBuilder(String) - Method in class io.grpc.util.ForwardingLoadBalancerHelper
-
Deprecated.
- createResolvingOobChannelBuilder(String, ChannelCredentials) - Method in class io.grpc.internal.ManagedChannelImpl.LbHelperImpl
- createResolvingOobChannelBuilder(String, ChannelCredentials) - Method in class io.grpc.LoadBalancer.Helper
-
Creates an out-of-band channel builder for LoadBalancer's own RPC needs, e.g., talking to an external load-balancer service, that is specified by a target string and credentials.
- createResolvingOobChannelBuilder(String, ChannelCredentials) - Method in class io.grpc.util.ForwardingLoadBalancerHelper
- createScheduledExecutor() - Method in interface io.grpc.internal.SharedResourceHolder.ScheduledExecutorFactory
- createServerCallHandler(ServerServiceDefinition) - Method in class io.grpc.protobuf.services.ProtoReflectionService
- createServerReflectionResponse(ServerReflectionRequest, Descriptors.FileDescriptor) - Method in class io.grpc.protobuf.services.ProtoReflectionServiceV1.ProtoReflectionStreamObserver
- createSocketAddress(SocketAddress, Attributes) - Method in class io.grpc.netty.NettyChannelBuilder.LocalSocketPicker
-
Called by gRPC to pick local socket to bind to.
- createStorage(AtomicReference<? super ClassNotFoundException>) - Static method in class io.grpc.Context.LazyStorage
- createStream(CreateStreamCommand, ChannelPromise) - Method in class io.grpc.netty.NettyClientHandler
-
Attempts to create a new stream from the given command.
- CreateStreamCommand - Class in io.grpc.netty
-
A command to create a new stream.
- CreateStreamCommand(Http2Headers, NettyClientStream.TransportState, boolean, boolean) - Constructor for class io.grpc.netty.CreateStreamCommand
- createStreamTraced(int, NettyClientStream.TransportState, Http2Headers, boolean, boolean, ChannelPromise) - Method in class io.grpc.netty.NettyClientHandler
- createSubchannel(LoadBalancer.CreateSubchannelArgs) - Method in class io.grpc.internal.ManagedChannelImpl.LbHelperImpl
- createSubchannel(LoadBalancer.CreateSubchannelArgs) - 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(LoadBalancer.CreateSubchannelArgs) - Method in class io.grpc.protobuf.services.HealthCheckingLoadBalancerFactory.HelperImpl
- createSubchannel(LoadBalancer.CreateSubchannelArgs) - Method in class io.grpc.util.ForwardingLoadBalancerHelper
- createSubchannel(LoadBalancer.CreateSubchannelArgs) - Method in class io.grpc.util.HealthProducerHelper
- createSubchannel(LoadBalancer.CreateSubchannelArgs) - Method in class io.grpc.util.OutlierDetectionLoadBalancer.ChildHelper
- CreateSubchannelArgs(List<EquivalentAddressGroup>, Attributes, Object[][]) - Constructor for class io.grpc.LoadBalancer.CreateSubchannelArgs
- createSubchannelAttrs() - Static method in class io.grpc.grpclb.GrpclbState
- createSubstream(int, boolean) - Method in class io.grpc.internal.RetriableStream
- createTrailers(StreamIdHolder, Http2Headers, Status) - Static method in class io.grpc.netty.SendResponseHeadersCommand
- createWithDefault(String, T) - Static method in class io.grpc.CallOptions.Key
-
Factory method for creating instances of
CallOptions.Key
. - createWithDefault(String, T) - Static method in class io.grpc.LoadBalancer.CreateSubchannelArgs.Key
-
Factory method for creating instances of
LoadBalancer.CreateSubchannelArgs.Key
. - CREATION_TIMESTAMP_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.ChannelTrace
- creationTimeNanos - Variable in class io.grpc.InternalChannelz.ChannelTrace.Builder
- creationTimeNanos - Variable in class io.grpc.InternalChannelz.ChannelTrace
- creationTimestamp_ - Variable in class io.grpc.channelz.v1.ChannelTrace.Builder
- creationTimestamp_ - Variable in class io.grpc.channelz.v1.ChannelTrace
- creationTimestampBuilder_ - Variable in class io.grpc.channelz.v1.ChannelTrace.Builder
- credentials - Variable in class io.grpc.CallOptions.Builder
- credentials - Variable in class io.grpc.CallOptions
- credentials1 - Variable in class io.grpc.CompositeCallCredentials
- credentials2 - Variable in class io.grpc.CompositeCallCredentials
- creds - Variable in class io.grpc.ChoiceChannelCredentials
- creds - Variable in class io.grpc.ChoiceServerCredentials
- CT_ERROR - Enum constant in enum io.grpc.channelz.v1.ChannelTraceEvent.Severity
-
CT_ERROR = 3;
- CT_ERROR - Enum constant in enum io.grpc.InternalChannelz.ChannelTrace.Event.Severity
- CT_ERROR_VALUE - Static variable in enum io.grpc.channelz.v1.ChannelTraceEvent.Severity
-
CT_ERROR = 3;
- CT_INFO - Enum constant in enum io.grpc.channelz.v1.ChannelTraceEvent.Severity
-
CT_INFO = 1;
- CT_INFO - Enum constant in enum io.grpc.InternalChannelz.ChannelTrace.Event.Severity
- CT_INFO_VALUE - Static variable in enum io.grpc.channelz.v1.ChannelTraceEvent.Severity
-
CT_INFO = 1;
- CT_UNKNOWN - Enum constant in enum io.grpc.channelz.v1.ChannelTraceEvent.Severity
-
CT_UNKNOWN = 0;
- CT_UNKNOWN - Enum constant in enum io.grpc.InternalChannelz.ChannelTrace.Event.Severity
- CT_UNKNOWN_VALUE - Static variable in enum io.grpc.channelz.v1.ChannelTraceEvent.Severity
-
CT_UNKNOWN = 0;
- CT_WARNING - Enum constant in enum io.grpc.channelz.v1.ChannelTraceEvent.Severity
-
CT_WARNING = 2;
- CT_WARNING - Enum constant in enum io.grpc.InternalChannelz.ChannelTrace.Event.Severity
- CT_WARNING_VALUE - Static variable in enum io.grpc.channelz.v1.ChannelTraceEvent.Severity
-
CT_WARNING = 2;
- ctx - Variable in class io.grpc.internal.MetadataApplierImpl
- ctx - Variable in class io.grpc.netty.AbstractNettyHandler
- ctx - Variable in class io.grpc.netty.NettyServerHandler.KeepAlivePinger
- ctx() - Method in class io.grpc.netty.AbstractNettyHandler
- cumulate(ByteBufAllocator, ByteBuf, ByteBuf) - Method in class io.grpc.netty.NettyAdaptiveCumulator
-
"Adaptive" cumulator: cumulate
ByteBuf
s by dynamically switching between merge and compose strategies. - current - Variable in class io.grpc.internal.MessageFramer.BufferChainOutputStream
- current - Variable in class io.grpc.netty.GrpcHttp2OutboundHeaders.Itr
- current() - Static method in class io.grpc.Context
-
Return the context associated with the current scope, will never return
null
. - current() - Method in class io.grpc.Context.Storage
-
Implements
Context.current()
. - current() - Method in class io.grpc.ThreadLocalContextStorage
- currentBalancerFactory - Variable in class io.grpc.util.GracefulSwitchLoadBalancer
- currentCertTime - Variable in class io.grpc.util.AdvancedTlsX509KeyManager.LoadFilePathExecution
- currentConnectivityState - Variable in class io.grpc.util.MultiChildLoadBalancer
- currentContextExecutor(Executor) - Static method in class io.grpc.Context
-
Create an executor that propagates the
Context.current()
context whenExecutor.execute(java.lang.Runnable)
is called as theContext.current()
context of theRunnable
scheduled. - currentIndex - Variable in class io.grpc.rls.AdaptiveThrottler.TimeBasedAccumulator
-
The current index into the slot array.
- currentKeyTime - Variable in class io.grpc.util.AdvancedTlsX509KeyManager.LoadFilePathExecution
- currentLb - Variable in class io.grpc.util.GracefulSwitchLoadBalancer
- currentLbIsReady - Variable in class io.grpc.util.GracefulSwitchLoadBalancer
- currentMessageSeqNo - Variable in class io.grpc.internal.MessageDeframer
- currentMessageSeqNo - Variable in class io.grpc.internal.MessageFramer
- currentMessageWireSize - Variable in class io.grpc.internal.MessageFramer
- currentPicker - Variable in class io.grpc.grpclb.GrpclbState
- currentPicker - Variable in class io.grpc.util.MultiChildLoadBalancer.ChildLbState
- currentPicker - Variable in class io.grpc.util.RoundRobinLoadBalancer
- currentServiceConfigOrError - Variable in class io.grpc.internal.ServiceConfigState
- currentState - Variable in class io.grpc.internal.PickFirstLoadBalancer
- currentState - Variable in class io.grpc.rls.SubchannelStateManagerImpl
- currentState - Variable in class io.grpc.util.MultiChildLoadBalancer.ChildLbState
- currentTime - Variable in class io.grpc.util.AdvancedTlsX509TrustManager.LoadFilePathExecution
- currentTimeNanos() - Method in interface io.grpc.internal.TimeProvider
-
Returns the current nano time.
- currentTimeNanos() - Method in interface io.grpc.protobuf.services.BinlogHelper.TimeProvider
-
Returns the current nano time.
- CUSTOM_MANAGERS - Enum constant in enum io.grpc.TlsChannelCredentials.Feature
-
Key managers and trust managers may be specified as
KeyManager
andTrustManager
objects. - CUSTOM_MANAGERS - Enum constant in enum io.grpc.TlsServerCredentials.Feature
-
Key managers and trust managers may be specified as
KeyManager
andTrustManager
objects. - customOptions - Variable in class io.grpc.CallOptions.Builder
- customOptions - Variable in class io.grpc.CallOptions
- customOptions - Variable in class io.grpc.LoadBalancer.CreateSubchannelArgs.Builder
- customOptions - Variable in class io.grpc.LoadBalancer.CreateSubchannelArgs
D
- data - Variable in class io.grpc.Attributes
- data - Variable in class io.grpc.internal.Http2Ping
-
The PING frame includes 8 octets of payload data, e.g.
- data - Variable in class io.grpc.InternalChannelz.SocketStats
- data(int) - Method in class io.grpc.Attributes.Builder
- data_ - Variable in class io.grpc.binarylog.v1.Message.Builder
- data_ - Variable in class io.grpc.binarylog.v1.Message
- data_ - Variable in class io.grpc.channelz.v1.Channel.Builder
- data_ - Variable in class io.grpc.channelz.v1.Channel
- data_ - Variable in class io.grpc.channelz.v1.Server.Builder
- data_ - Variable in class io.grpc.channelz.v1.Server
- data_ - Variable in class io.grpc.channelz.v1.Socket.Builder
- data_ - Variable in class io.grpc.channelz.v1.Socket
- data_ - Variable in class io.grpc.channelz.v1.Subchannel.Builder
- data_ - Variable in class io.grpc.channelz.v1.Subchannel
- DATA_FIELD_NUMBER - Static variable in class io.grpc.binarylog.v1.Message
- DATA_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.Channel
- DATA_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.Server
- DATA_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.Socket
- DATA_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.Subchannel
- DATA_LOSS - Enum constant in enum io.grpc.Status.Code
-
Unrecoverable data loss or corruption.
- DATA_LOSS - Static variable in class io.grpc.Status
-
Unrecoverable data loss or corruption.
- dataBuilder_ - Variable in class io.grpc.channelz.v1.Channel.Builder
- dataBuilder_ - Variable in class io.grpc.channelz.v1.Server.Builder
- dataBuilder_ - Variable in class io.grpc.channelz.v1.Socket.Builder
- dataBuilder_ - Variable in class io.grpc.channelz.v1.Subchannel.Builder
- dataCacheEntry - Variable in class io.grpc.rls.CachingRlsLbClient.CachedRouteLookupResponse
- DataCacheEntry(RlsProtoData.RouteLookupRequest, RlsProtoData.RouteLookupResponse) - Constructor for class io.grpc.rls.CachingRlsLbClient.DataCacheEntry
- dataEntry(CachingRlsLbClient.DataCacheEntry) - Static method in class io.grpc.rls.CachingRlsLbClient.CachedRouteLookupResponse
- dataSizeSincePing - Variable in class io.grpc.netty.AbstractNettyHandler.FlowControlPinger
- deadline - Variable in class io.grpc.CallOptions.Builder
- deadline - Variable in class io.grpc.CallOptions
- deadline - Variable in class io.grpc.Context.CancellableContext
- Deadline - Class in io.grpc
-
An absolute point in time, generally for tracking when a task should be completed.
- Deadline(Deadline.Ticker, long, boolean) - Constructor for class io.grpc.Deadline
- Deadline(Deadline.Ticker, long, long, boolean) - Constructor for class io.grpc.Deadline
- DEADLINE_EXCEEDED - Enum constant in enum io.grpc.Status.Code
-
Deadline expired before operation could complete.
- DEADLINE_EXCEEDED - Static variable in class io.grpc.Status
-
Deadline expired before operation could complete.
- Deadline.SystemTicker - Class in io.grpc
- Deadline.Ticker - Class in io.grpc
-
Time source representing nanoseconds since fixed but arbitrary point in time.
- deadlineCancellationExecutor - Variable in class io.grpc.internal.ClientCallImpl
- deadlineCancellationExecutor - Variable in class io.grpc.internal.OobChannel
- deadlineCancellationExecutor - Variable in class io.grpc.internal.SubchannelChannel
- deadlineCancellationFuture - Variable in class io.grpc.internal.ClientCallImpl.CancellationHandler
- deadlineNanos - Variable in class io.grpc.Deadline
- deadlineTicker(Deadline.Ticker) - Method in class io.grpc.inprocess.InProcessServerBuilder
-
Provides a custom deadline ticker that this server will use to create incoming
Deadline
s. - deallocate() - Method in class io.grpc.netty.NettyServer.SharedResourceReferenceCounter
- deallocated - Variable in class io.grpc.internal.AbstractStream.TransportState
-
Indicates that the stream no longer exists for the transport.
- DEBUG - Enum constant in enum io.grpc.ChannelLogger.ChannelLogLevel
- debugString - Variable in class io.grpc.Attributes.Key
- debugString - Variable in class io.grpc.CallOptions.Key
- debugString - Variable in class io.grpc.LoadBalancer.CreateSubchannelArgs.Key
- 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 - Variable in class io.grpc.DecompressorRegistry.DecompressorInfo
- decompressor - Variable in class io.grpc.internal.MessageDeframer
- Decompressor - Interface in io.grpc
-
Represents a message decompressor.
- DecompressorInfo(Decompressor, boolean) - Constructor for class io.grpc.DecompressorRegistry.DecompressorInfo
- decompressorRegistry - Variable in class io.grpc.internal.AbstractClientStream.TransportState
- decompressorRegistry - Variable in class io.grpc.internal.ClientCallImpl
- decompressorRegistry - Variable in class io.grpc.internal.ManagedChannelImpl
- decompressorRegistry - Variable in class io.grpc.internal.ManagedChannelImplBuilder
- decompressorRegistry - Variable in class io.grpc.internal.ServerCallImpl
- decompressorRegistry - Variable in class io.grpc.internal.ServerImpl
- decompressorRegistry - Variable in class io.grpc.internal.ServerImplBuilder
- decompressorRegistry(DecompressorRegistry) - Method in class io.grpc.ForwardingChannelBuilder
- decompressorRegistry(DecompressorRegistry) - Method in class io.grpc.ForwardingChannelBuilder2
- decompressorRegistry(DecompressorRegistry) - Method in class io.grpc.ForwardingServerBuilder
- decompressorRegistry(DecompressorRegistry) - Method in class io.grpc.internal.ManagedChannelImplBuilder
- decompressorRegistry(DecompressorRegistry) - Method in class io.grpc.internal.ServerImplBuilder
- 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.
- DecompressorRegistry - Class in io.grpc
-
Encloses classes related to the compression and decompression of messages.
- DecompressorRegistry() - Constructor for class io.grpc.DecompressorRegistry
- DecompressorRegistry(Decompressor, boolean, DecompressorRegistry) - Constructor for class io.grpc.DecompressorRegistry
- DecompressorRegistry.DecompressorInfo - Class in io.grpc
-
Information about a decompressor.
- decompressors - Variable in class io.grpc.DecompressorRegistry
- decrementEjectionTimeMultiplier() - Method in class io.grpc.util.OutlierDetectionLoadBalancer.EndpointTracker
- deDupAddresses(List<EquivalentAddressGroup>) - Static method in class io.grpc.internal.PickFirstLeafLoadBalancer
- DEFAULT - Static variable in class io.grpc.CallOptions
-
A blank
CallOptions
that all fields are not set. - DEFAULT - Static variable in class io.grpc.netty.ProtocolNegotiationEvent
- DEFAULT - Static variable in class io.grpc.rls.RlsProtoData.ExtraKeys
- DEFAULT - Static variable in class io.grpc.servlet.AsyncServletOutputStreamWriter.WriteState
- DEFAULT - Static variable in class io.grpc.servlet.jakarta.AsyncServletOutputStreamWriter.WriteState
- DEFAULT_AUTHENTICATOR - Static variable in class io.grpc.internal.ProxyDetectorImpl
- DEFAULT_AUTO_FLOW_CONTROL - Static variable in class io.grpc.netty.NettyChannelBuilder
- DEFAULT_BOSS_EVENT_LOOP_GROUP - Static variable in class io.grpc.netty.Utils
- DEFAULT_BOSS_EVENT_LOOP_GROUP_POOL - Static variable in class io.grpc.netty.NettyServerBuilder
- DEFAULT_CHANNEL_FACTORY - Static variable in class io.grpc.netty.NettyChannelBuilder
- DEFAULT_CHANNELZ_MAX_PAGE_SIZE - Static variable in class io.grpc.services.AdminInterface
- DEFAULT_CLIENT_CHANNEL_TYPE - Static variable in class io.grpc.netty.Utils
- DEFAULT_COMPRESSOR_REGISTRY - Static variable in class io.grpc.internal.ManagedChannelImplBuilder
- DEFAULT_COMPRESSOR_REGISTRY - Static variable in class io.grpc.internal.ServerImplBuilder
- DEFAULT_CONFIG - Static variable in class io.grpc.grpclb.GrpclbLoadBalancer
- DEFAULT_DECOMPRESSOR_REGISTRY - Static variable in class io.grpc.internal.ManagedChannelImplBuilder
- DEFAULT_DECOMPRESSOR_REGISTRY - Static variable in class io.grpc.internal.ServerImplBuilder
- DEFAULT_EVENT_LOOP_GROUP_POOL - Static variable in class io.grpc.netty.NettyChannelBuilder
- DEFAULT_EXECUTOR_POOL - Static variable in class io.grpc.internal.ManagedChannelImplBuilder
- DEFAULT_EXECUTOR_POOL - Static variable in class io.grpc.internal.ServerImplBuilder
- DEFAULT_FACTORY - Static variable in class io.grpc.internal.CallTracer
- DEFAULT_FACTORY - Static variable in class io.grpc.internal.TransportTracer
- DEFAULT_FALLBACK_REGISTRY - Static variable in class io.grpc.internal.ServerImplBuilder
- 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_HANDSHAKE_TIMEOUT_MILLIS - Static variable in class io.grpc.internal.ServerImplBuilder
- DEFAULT_HISTORY_SECONDS - Static variable in class io.grpc.rls.AdaptiveThrottler
- DEFAULT_INSTANCE - Static variable in class io.grpc.binarylog.v1.Address
- DEFAULT_INSTANCE - Static variable in class io.grpc.binarylog.v1.ClientHeader
- DEFAULT_INSTANCE - Static variable in class io.grpc.binarylog.v1.GrpcLogEntry
- DEFAULT_INSTANCE - Static variable in class io.grpc.binarylog.v1.Message
- DEFAULT_INSTANCE - Static variable in class io.grpc.binarylog.v1.Metadata
- DEFAULT_INSTANCE - Static variable in class io.grpc.binarylog.v1.MetadataEntry
- DEFAULT_INSTANCE - Static variable in class io.grpc.binarylog.v1.ServerHeader
- DEFAULT_INSTANCE - Static variable in class io.grpc.binarylog.v1.Trailer
- DEFAULT_INSTANCE - Static variable in class io.grpc.channelz.v1.Address
- DEFAULT_INSTANCE - Static variable in class io.grpc.channelz.v1.Address.OtherAddress
- DEFAULT_INSTANCE - Static variable in class io.grpc.channelz.v1.Address.TcpIpAddress
- DEFAULT_INSTANCE - Static variable in class io.grpc.channelz.v1.Address.UdsAddress
- DEFAULT_INSTANCE - Static variable in class io.grpc.channelz.v1.Channel
- DEFAULT_INSTANCE - Static variable in class io.grpc.channelz.v1.ChannelConnectivityState
- DEFAULT_INSTANCE - Static variable in class io.grpc.channelz.v1.ChannelData
- DEFAULT_INSTANCE - Static variable in class io.grpc.channelz.v1.ChannelRef
- DEFAULT_INSTANCE - Static variable in class io.grpc.channelz.v1.ChannelTrace
- DEFAULT_INSTANCE - Static variable in class io.grpc.channelz.v1.ChannelTraceEvent
- DEFAULT_INSTANCE - Static variable in class io.grpc.channelz.v1.GetChannelRequest
- DEFAULT_INSTANCE - Static variable in class io.grpc.channelz.v1.GetChannelResponse
- DEFAULT_INSTANCE - Static variable in class io.grpc.channelz.v1.GetServerRequest
- DEFAULT_INSTANCE - Static variable in class io.grpc.channelz.v1.GetServerResponse
- DEFAULT_INSTANCE - Static variable in class io.grpc.channelz.v1.GetServerSocketsRequest
- DEFAULT_INSTANCE - Static variable in class io.grpc.channelz.v1.GetServerSocketsResponse
- DEFAULT_INSTANCE - Static variable in class io.grpc.channelz.v1.GetServersRequest
- DEFAULT_INSTANCE - Static variable in class io.grpc.channelz.v1.GetServersResponse
- DEFAULT_INSTANCE - Static variable in class io.grpc.channelz.v1.GetSocketRequest
- DEFAULT_INSTANCE - Static variable in class io.grpc.channelz.v1.GetSocketResponse
- DEFAULT_INSTANCE - Static variable in class io.grpc.channelz.v1.GetSubchannelRequest
- DEFAULT_INSTANCE - Static variable in class io.grpc.channelz.v1.GetSubchannelResponse
- DEFAULT_INSTANCE - Static variable in class io.grpc.channelz.v1.GetTopChannelsRequest
- DEFAULT_INSTANCE - Static variable in class io.grpc.channelz.v1.GetTopChannelsResponse
- DEFAULT_INSTANCE - Static variable in class io.grpc.channelz.v1.Security
- DEFAULT_INSTANCE - Static variable in class io.grpc.channelz.v1.Security.OtherSecurity
- DEFAULT_INSTANCE - Static variable in class io.grpc.channelz.v1.Security.Tls
- DEFAULT_INSTANCE - Static variable in class io.grpc.channelz.v1.Server
- DEFAULT_INSTANCE - Static variable in class io.grpc.channelz.v1.ServerData
- DEFAULT_INSTANCE - Static variable in class io.grpc.channelz.v1.ServerRef
- DEFAULT_INSTANCE - Static variable in class io.grpc.channelz.v1.Socket
- DEFAULT_INSTANCE - Static variable in class io.grpc.channelz.v1.SocketData
- DEFAULT_INSTANCE - Static variable in class io.grpc.channelz.v1.SocketOption
- DEFAULT_INSTANCE - Static variable in class io.grpc.channelz.v1.SocketOptionLinger
- DEFAULT_INSTANCE - Static variable in class io.grpc.channelz.v1.SocketOptionTcpInfo
- DEFAULT_INSTANCE - Static variable in class io.grpc.channelz.v1.SocketOptionTimeout
- DEFAULT_INSTANCE - Static variable in class io.grpc.channelz.v1.SocketRef
- DEFAULT_INSTANCE - Static variable in class io.grpc.channelz.v1.Subchannel
- DEFAULT_INSTANCE - Static variable in class io.grpc.channelz.v1.SubchannelRef
- DEFAULT_INSTANCE - Static variable in class io.grpc.CompressorRegistry
- DEFAULT_INSTANCE - Static variable in class io.grpc.DecompressorRegistry
- DEFAULT_INSTANCE - Static variable in class io.grpc.health.v1.HealthCheckRequest
- DEFAULT_INSTANCE - Static variable in class io.grpc.health.v1.HealthCheckResponse
- DEFAULT_INSTANCE - Static variable in class io.grpc.lb.v1.ClientStats
- DEFAULT_INSTANCE - Static variable in class io.grpc.lb.v1.ClientStatsPerToken
- DEFAULT_INSTANCE - Static variable in class io.grpc.lb.v1.FallbackResponse
- DEFAULT_INSTANCE - Static variable in class io.grpc.lb.v1.InitialLoadBalanceRequest
- DEFAULT_INSTANCE - Static variable in class io.grpc.lb.v1.InitialLoadBalanceResponse
- DEFAULT_INSTANCE - Static variable in class io.grpc.lb.v1.LoadBalanceRequest
- DEFAULT_INSTANCE - Static variable in class io.grpc.lb.v1.LoadBalanceResponse
- DEFAULT_INSTANCE - Static variable in class io.grpc.lb.v1.Server
- DEFAULT_INSTANCE - Static variable in class io.grpc.lb.v1.ServerList
- DEFAULT_INSTANCE - Static variable in class io.grpc.lookup.v1.GrpcKeyBuilder
- DEFAULT_INSTANCE - Static variable in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys
- DEFAULT_INSTANCE - Static variable in class io.grpc.lookup.v1.GrpcKeyBuilder.Name
- DEFAULT_INSTANCE - Static variable in class io.grpc.lookup.v1.HttpKeyBuilder
- DEFAULT_INSTANCE - Static variable in class io.grpc.lookup.v1.NameMatcher
- DEFAULT_INSTANCE - Static variable in class io.grpc.lookup.v1.RouteLookupClusterSpecifier
- DEFAULT_INSTANCE - Static variable in class io.grpc.lookup.v1.RouteLookupConfig
- DEFAULT_INSTANCE - Static variable in class io.grpc.lookup.v1.RouteLookupRequest
- DEFAULT_INSTANCE - Static variable in class io.grpc.lookup.v1.RouteLookupResponse
- DEFAULT_INSTANCE - Static variable in class io.grpc.reflection.v1.ErrorResponse
- DEFAULT_INSTANCE - Static variable in class io.grpc.reflection.v1.ExtensionNumberResponse
- DEFAULT_INSTANCE - Static variable in class io.grpc.reflection.v1.ExtensionRequest
- DEFAULT_INSTANCE - Static variable in class io.grpc.reflection.v1.FileDescriptorResponse
- DEFAULT_INSTANCE - Static variable in class io.grpc.reflection.v1.ListServiceResponse
- DEFAULT_INSTANCE - Static variable in class io.grpc.reflection.v1.ServerReflectionRequest
- DEFAULT_INSTANCE - Static variable in class io.grpc.reflection.v1.ServerReflectionResponse
- DEFAULT_INSTANCE - Static variable in class io.grpc.reflection.v1.ServiceResponse
- DEFAULT_INSTANCE - Static variable in class io.grpc.reflection.v1alpha.ErrorResponse
- DEFAULT_INSTANCE - Static variable in class io.grpc.reflection.v1alpha.ExtensionNumberResponse
- DEFAULT_INSTANCE - Static variable in class io.grpc.reflection.v1alpha.ExtensionRequest
- DEFAULT_INSTANCE - Static variable in class io.grpc.reflection.v1alpha.FileDescriptorResponse
- DEFAULT_INSTANCE - Static variable in class io.grpc.reflection.v1alpha.ListServiceResponse
- DEFAULT_INSTANCE - Static variable in class io.grpc.reflection.v1alpha.ServerReflectionRequest
- DEFAULT_INSTANCE - Static variable in class io.grpc.reflection.v1alpha.ServerReflectionResponse
- DEFAULT_INSTANCE - Static variable in class io.grpc.reflection.v1alpha.ServiceResponse
- DEFAULT_KEEPALIVE_TIMEOUT_NANOS - Static variable in class io.grpc.internal.GrpcUtil
-
The default timeout in nanos for a keepalive ping request.
- DEFAULT_LB_POLICY - Static variable in class io.grpc.internal.GrpcUtil
-
The very default load-balancing policy.
- DEFAULT_LOOKUP_SERVICE_TIMEOUT - Static variable in class io.grpc.rls.RlsProtoConverters
- 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_MAX_MESSAGE_SIZE - Static variable in class io.grpc.protobuf.lite.ProtoLiteUtils
-
The same value as
GrpcUtil.DEFAULT_MAX_MESSAGE_SIZE
. - DEFAULT_MODE - Static variable in class io.grpc.grpclb.GrpclbLoadBalancerProvider
- DEFAULT_NETWORK_CACHE_TTL_SECONDS - Static variable in class io.grpc.internal.DnsNameResolver
-
Default DNS cache duration if network cache ttl value is not specified (
null
). - DEFAULT_ONREADY_THRESHOLD - Static variable in class io.grpc.internal.AbstractStream.TransportState
-
The default number of queued bytes for a given stream, below which
StreamListener.onReady()
will be called. - DEFAULT_PER_RPC_BUFFER_LIMIT_IN_BYTES - Static variable in class io.grpc.internal.ManagedChannelImplBuilder
- 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_PROXY_SELECTOR - Static variable in class io.grpc.internal.ProxyDetectorImpl
- DEFAULT_RATIO_FOR_ACCEPT - Static variable in class io.grpc.rls.AdaptiveThrottler
- DEFAULT_REQUEST_PADDING - Static variable in class io.grpc.rls.AdaptiveThrottler
- DEFAULT_RETRY_BUFFER_SIZE_IN_BYTES - Static variable in class io.grpc.internal.ManagedChannelImplBuilder
- DEFAULT_SERVER_CHANNEL_FACTORY - Static variable in class io.grpc.netty.Utils
- 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.
- DEFAULT_TARGET_FIELD_NUMBER - Static variable in class io.grpc.lookup.v1.RouteLookupConfig
- DEFAULT_TARGET_PICKS_COUNTER - Static variable in class io.grpc.rls.CachingRlsLbClient
- DEFAULT_WORKER_EVENT_LOOP_GROUP - Static variable in class io.grpc.netty.Utils
- DEFAULT_WORKER_EVENT_LOOP_GROUP_POOL - Static variable in class io.grpc.netty.NettyServerBuilder
- defaultAppExecutor - Variable in class io.grpc.internal.DelayedClientTransport
- defaultBalancer - Variable in class io.grpc.util.GracefulSwitchLoadBalancer
- DefaultCachingRlsLbClientBuilderProvider() - Constructor for class io.grpc.rls.RlsLoadBalancer.DefaultCachingRlsLbClientBuilderProvider
- DefaultChannelCreds() - Constructor for class io.grpc.internal.ManagedChannelImpl.LbHelperImpl.DefaultChannelCreds
- defaultConstructor - Static variable in class io.grpc.internal.ReflectionLongAdderCounter
- defaultEntry - Static variable in class io.grpc.lookup.v1.GrpcKeyBuilder.ConstantKeysDefaultEntryHolder
- defaultEntry - Static variable in class io.grpc.lookup.v1.HttpKeyBuilder.ConstantKeysDefaultEntryHolder
- defaultEntry - Static variable in class io.grpc.lookup.v1.RouteLookupRequest.KeyMapDefaultEntryHolder
- DefaultEventLoopGroupResource(int, String, Utils.EventLoopGroupType) - Constructor for class io.grpc.netty.Utils.DefaultEventLoopGroupResource
- DefaultFallbackRegistry() - Constructor for class io.grpc.internal.ServerImplBuilder.DefaultFallbackRegistry
- defaultInstance - Variable in class io.grpc.protobuf.lite.ProtoLiteUtils.MessageMarshaller
- defaultInstance - Variable in class io.grpc.protobuf.lite.ProtoLiteUtils.MetadataMarshaller
- defaultLbPolicy - Variable in class io.grpc.internal.ManagedChannelImplBuilder
- defaultLoadBalancingPolicy(String) - Method in class io.grpc.ForwardingChannelBuilder
- defaultLoadBalancingPolicy(String) - Method in class io.grpc.ForwardingChannelBuilder2
- defaultLoadBalancingPolicy(String) - Method in class io.grpc.internal.ManagedChannelImplBuilder
- defaultLoadBalancingPolicy(String) - Method in class io.grpc.ManagedChannelBuilder
-
Sets the default load-balancing policy that will be used if the service config doesn't specify one.
- defaultMethodConfig - Variable in class io.grpc.internal.ManagedChannelServiceConfig
- defaultPolicy - Variable in class io.grpc.internal.AutoConfiguredLoadBalancerFactory
- defaultPort - Variable in class io.grpc.NameResolver.Args.Builder
- defaultPort - Variable in class io.grpc.NameResolver.Args
- DefaultProtocolNegotiator() - Constructor for class io.grpc.netty.NettyChannelBuilder.DefaultProtocolNegotiator
- defaultScheme - Variable in class io.grpc.NameResolverRegistry
- defaultServiceConfig - Variable in class io.grpc.internal.ManagedChannelImpl
- defaultServiceConfig - Variable in class io.grpc.internal.ManagedChannelImplBuilder
- defaultServiceConfig - Variable in class io.grpc.internal.ServiceConfigState
- defaultServiceConfig(Map<String, ?>) - Method in class io.grpc.ForwardingChannelBuilder
- defaultServiceConfig(Map<String, ?>) - Method in class io.grpc.ForwardingChannelBuilder2
- defaultServiceConfig(Map<String, ?>) - Method in class io.grpc.internal.ManagedChannelImplBuilder
- defaultServiceConfig(Map<String, ?>) - Method in class io.grpc.ManagedChannelBuilder
-
Provides a service config to the channel.
- defaultSslProvider() - Static method in class io.grpc.netty.GrpcSslContexts
-
Returns OpenSSL if available, otherwise returns the JDK provider.
- defaultTarget - Variable in class io.grpc.rls.AutoValue_RlsProtoData_RouteLookupConfig.Builder
- defaultTarget - Variable in class io.grpc.rls.AutoValue_RlsProtoData_RouteLookupConfig
- defaultTarget() - Method in class io.grpc.rls.AutoValue_RlsProtoData_RouteLookupConfig
- defaultTarget() - Method in class io.grpc.rls.RlsProtoData.RouteLookupConfig
-
Returns the default target to use if needed.
- defaultTarget(String) - Method in class io.grpc.rls.AutoValue_RlsProtoData_RouteLookupConfig.Builder
- defaultTarget(String) - Method in class io.grpc.rls.RlsProtoData.RouteLookupConfig.Builder
- defaultTarget_ - Variable in class io.grpc.lookup.v1.RouteLookupConfig.Builder
- defaultTarget_ - Variable in class io.grpc.lookup.v1.RouteLookupConfig
- defaultValue - Variable in class io.grpc.CallOptions.Key
- defaultValue - Variable in class io.grpc.Context.Key
- defaultValue - Variable in class io.grpc.LoadBalancer.CreateSubchannelArgs.Key
- deflatedBytesConsumed - Variable in class io.grpc.internal.GzipInflatingBuffer
-
Tracks deflated bytes (excluding gzip metadata) consumed by the inflater.
- 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
- deframe(ReadableBuffer) - Method in class io.grpc.internal.MigratingThreadDeframer
- deframeFailed(Throwable) - Method in class io.grpc.internal.ApplicationThreadDeframerListener
- deframeFailed(Throwable) - Method in class io.grpc.internal.ForwardingDeframerListener
- deframeFailed(Throwable) - Method in interface io.grpc.internal.MessageDeframer.Listener
-
Called when a
MessageDeframer.deframe(ReadableBuffer)
operation failed. - deframeFailed(Throwable) - Method in class io.grpc.internal.SquelchLateMessagesAvailableDeframerListener
- deframeFailed(Throwable) - Method in class io.grpc.netty.NettyClientStream.TransportState
- deframeFailed(Throwable) - Method in class io.grpc.netty.NettyServerStream.TransportState
- deframeFailed(Throwable) - Method in class io.grpc.servlet.jakarta.ServletServerStream.ServletTransportState
- deframeFailed(Throwable) - Method in class io.grpc.servlet.ServletServerStream.ServletTransportState
- DeframeMessageProducer() - Constructor for class io.grpc.internal.MigratingThreadDeframer.DeframeMessageProducer
- deframer - Variable in class io.grpc.internal.AbstractStream.TransportState
- deframer - Variable in class io.grpc.internal.ApplicationThreadDeframer
- deframer - Variable in class io.grpc.internal.MigratingThreadDeframer
- Deframer - Interface in io.grpc.internal
-
Interface for deframing gRPC messages.
- deframerClosed - Variable in class io.grpc.internal.AbstractClientStream.TransportState
- deframerClosed - Variable in class io.grpc.internal.AbstractServerStream.TransportState
- 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.ApplicationThreadDeframerListener
- deframerClosed(boolean) - Method in class io.grpc.internal.ForwardingDeframerListener
- deframerClosed(boolean) - Method in interface io.grpc.internal.MessageDeframer.Listener
-
Called when the deframer closes.
- deframerClosed(boolean) - Method in class io.grpc.internal.SquelchLateMessagesAvailableDeframerListener
- deframerClosedTask - Variable in class io.grpc.internal.AbstractClientStream.TransportState
- deframerClosedTask - Variable in class io.grpc.internal.AbstractServerStream.TransportState
- deframerOnTransportThread - Variable in class io.grpc.internal.MigratingThreadDeframer
-
true
means decoding on transport thread. - DelayedClientCall<ReqT,
RespT> - Class in io.grpc.internal -
A call that queues requests before a real call is ready to be delegated to.
- DelayedClientCall(Executor, ScheduledExecutorService, Deadline) - Constructor for class io.grpc.internal.DelayedClientCall
- DelayedClientCall.CloseListenerRunnable - Class in io.grpc.internal
- DelayedClientCall.DelayedListener<RespT> - Class in io.grpc.internal
- DelayedClientTransport - Class in io.grpc.internal
-
A client transport that queues requests before a real transport is available.
- DelayedClientTransport(Executor, SynchronizationContext) - Constructor for class io.grpc.internal.DelayedClientTransport
-
Creates a new delayed transport.
- DelayedClientTransport.PendingStream - Class in io.grpc.internal
- DelayedClientTransport.PickerState - Class in io.grpc.internal
- delayedListener - Variable in class io.grpc.internal.DelayedClientCall
- delayedListener - Variable in class io.grpc.internal.DelayedStream
- DelayedListener(ClientCall.Listener<RespT>) - Constructor for class io.grpc.internal.DelayedClientCall.DelayedListener
- DelayedNameResolverRefresh() - Constructor for class io.grpc.internal.RetryingNameResolver.DelayedNameResolverRefresh
- delayedShutdownTask - Variable in class io.grpc.internal.ManagedChannelImpl.SubchannelImpl
- delayedStream - Variable in class io.grpc.internal.MetadataApplierImpl
- DelayedStream - Class in io.grpc.internal
-
A stream that queues requests before the transport is available, and delegates to a real stream implementation when the transport is available.
- DelayedStream() - Constructor for class io.grpc.internal.DelayedStream
- DelayedStream.DelayedStreamListener - Class in io.grpc.internal
- DelayedStreamListener(ClientStreamListener) - Constructor for class io.grpc.internal.DelayedStream.DelayedStreamListener
- delayedTransport - Variable in class io.grpc.internal.ManagedChannelImpl
- delayedTransport - Variable in class io.grpc.internal.OobChannel
- delayedTransportListener - Variable in class io.grpc.internal.ManagedChannelImpl
- DelayedTransportListener() - Constructor for class io.grpc.internal.ManagedChannelImpl.DelayedTransportListener
- delayOrExecute(RetriableStream.BufferEntry) - Method in class io.grpc.internal.RetriableStream
- delayOrExecute(Runnable) - Method in class io.grpc.internal.DelayedClientCall.DelayedListener
- delayOrExecute(Runnable) - Method in class io.grpc.internal.DelayedClientCall
- delayOrExecute(Runnable) - Method in class io.grpc.internal.DelayedStream.DelayedStreamListener
- delayOrExecute(Runnable) - Method in class io.grpc.internal.DelayedStream
-
Enqueue the runnable or execute it now.
- delegate - Variable in class io.grpc.ClientInterceptors.CheckedForwardingClientCall
- delegate - Variable in class io.grpc.CompositeCallCredentials.CombiningMetadataApplier
- delegate - Variable in class io.grpc.CompositeCallCredentials.WrappingMetadataApplier
- delegate - Variable in class io.grpc.ForwardingClientCall.SimpleForwardingClientCall
- delegate - Variable in class io.grpc.ForwardingClientCallListener.SimpleForwardingClientCallListener
- delegate - Variable in class io.grpc.ForwardingServerCall.SimpleForwardingServerCall
- delegate - Variable in class io.grpc.ForwardingServerCallListener.SimpleForwardingServerCallListener
- delegate - Variable in class io.grpc.grpclb.TokenAttachingTracerFactory
- delegate - Variable in class io.grpc.internal.AutoConfiguredLoadBalancerFactory.AutoConfiguredLoadBalancer
- delegate - Variable in class io.grpc.internal.CallCredentialsApplyingTransportFactory.CallCredentialsApplyingTransport
- delegate - Variable in class io.grpc.internal.CallCredentialsApplyingTransportFactory
- delegate - Variable in class io.grpc.internal.ForwardingManagedChannel
- delegate - Variable in class io.grpc.internal.ForwardingNameResolver
- delegate - Variable in class io.grpc.internal.InternalSubchannel.CallTracingTransport
- delegate - Variable in class io.grpc.internal.ManagedChannelImpl.ConfigSelectingClientCall
- delegate - Variable in class io.grpc.internal.ManagedChannelImpl.RestrictedScheduledExecutor
- delegate - Variable in class io.grpc.internal.MigratingThreadDeframer.MigratingDeframerListener
- delegate - Variable in class io.grpc.internal.SquelchLateMessagesAvailableDeframerListener
- delegate - Variable in class io.grpc.protobuf.services.HealthCheckingLoadBalancerFactory.HealthCheckingLoadBalancer
- delegate - Variable in class io.grpc.protobuf.services.HealthCheckingLoadBalancerFactory.HelperImpl
- delegate - Variable in class io.grpc.protobuf.services.HealthCheckingLoadBalancerFactory.SubchannelImpl
- delegate - Variable in class io.grpc.rls.CachingRlsLbClient.AutoCleaningEvictionListener
- delegate - Variable in class io.grpc.rls.LbPolicyConfiguration.ChildPolicyWrapper.ChildPolicyReportingHelper
- delegate - Variable in class io.grpc.rls.LinkedHashLruCache
- delegate - Variable in class io.grpc.rls.LinkedHashLruCache.SizeHandlingEvictionListener
- delegate - Variable in class io.grpc.services.ChannelzService
-
Deprecated.
- delegate - Variable in class io.grpc.services.HealthStatusManager
-
Deprecated.
- delegate - Variable in class io.grpc.util.HealthProducerHelper
- delegate - Variable in class io.grpc.util.HealthProducerHelper.HealthProducerSubchannel
- delegate - Variable in class io.grpc.util.OutlierDetectionLoadBalancer.ChildHelper
- delegate - Variable in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionPicker
- delegate - Variable in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionSubchannel
- delegate - Variable in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionSubchannel.OutlierDetectionSubchannelStateListener
- delegate() - Method in class io.grpc.ClientInterceptors.CheckedForwardingClientCall
- delegate() - Method in class io.grpc.ForwardingChannelBuilder
-
Deprecated.As of 1.60.0, use
ForwardingChannelBuilder2
instead. - delegate() - Method in class io.grpc.ForwardingChannelBuilder2
-
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.ForwardingServerBuilder
-
Returns the delegated
ServerBuilder
. - 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.inprocess.InProcessChannelBuilder
- delegate() - Method in class io.grpc.inprocess.InProcessServerBuilder
- delegate() - Method in class io.grpc.internal.CallCredentialsApplyingTransportFactory.CallCredentialsApplyingTransport
- delegate() - Method in class io.grpc.internal.ForwardingClientStream
- delegate() - Method in class io.grpc.internal.ForwardingClientStreamListener
- delegate() - Method in class io.grpc.internal.ForwardingClientStreamTracer
-
Returns the underlying
ClientStreamTracer
. - delegate() - Method in class io.grpc.internal.ForwardingConnectionClientTransport
- delegate() - Method in class io.grpc.internal.ForwardingDeframerListener
- delegate() - Method in class io.grpc.internal.InternalSubchannel.CallTracingTransport
- delegate() - Method in class io.grpc.internal.ManagedChannelImpl.ConfigSelectingClientCall
- delegate() - Method in class io.grpc.internal.MigratingThreadDeframer.MigratingDeframerListener
- delegate() - Method in class io.grpc.internal.SquelchLateMessagesAvailableDeframerListener
- delegate() - Method in class io.grpc.netty.NettyChannelBuilder
- delegate() - Method in class io.grpc.netty.NettyServerBuilder
- delegate() - Method in class io.grpc.PartialForwardingClientCall
-
Returns the delegated
ClientCall
. - delegate() - Method in class io.grpc.PartialForwardingClientCallListener
-
Returns the delegated
ClientCall.Listener
. - delegate() - Method in class io.grpc.PartialForwardingServerCall
-
Returns the delegated
ServerCall
. - delegate() - Method in class io.grpc.PartialForwardingServerCallListener
-
Returns the delegated
ServerCall.Listener
. - delegate() - Method in class io.grpc.protobuf.services.HealthCheckingLoadBalancerFactory.HealthCheckingLoadBalancer
- delegate() - Method in class io.grpc.protobuf.services.HealthCheckingLoadBalancerFactory.HelperImpl
- delegate() - Method in class io.grpc.protobuf.services.HealthCheckingLoadBalancerFactory.SubchannelImpl
- delegate() - Method in class io.grpc.rls.CachingRlsLbClient.RlsLbHelper
- delegate() - Method in class io.grpc.rls.ChildLoadBalancerHelper
- delegate() - Method in class io.grpc.rls.LbPolicyConfiguration.ChildPolicyWrapper.ChildPolicyReportingHelper
- delegate() - Method in class io.grpc.ServerStreamTracer.ReadOnlyServerCall
-
Deprecated.
- delegate() - Method in class io.grpc.servlet.jakarta.ServletServerBuilder
- delegate() - Method in class io.grpc.servlet.ServletServerBuilder
- delegate() - Method in class io.grpc.util.ForwardingClientStreamTracer
-
Returns the underlying
ClientStreamTracer
. - delegate() - Method in class io.grpc.util.ForwardingLoadBalancer
-
Returns the underlying balancer.
- delegate() - Method in class io.grpc.util.ForwardingLoadBalancerHelper
-
Returns the underlying helper.
- delegate() - Method in class io.grpc.util.ForwardingSubchannel
-
Returns the underlying Subchannel.
- delegate() - Method in class io.grpc.util.GracefulSwitchLoadBalancer
- delegate() - Method in class io.grpc.util.HealthProducerHelper
- delegate() - Method in class io.grpc.util.HealthProducerHelper.HealthProducerSubchannel
- delegate() - Method in class io.grpc.util.MultiChildLoadBalancer.ChildLbState.ChildLbStateHelper
- delegate() - Method in class io.grpc.util.OutlierDetectionLoadBalancer.ChildHelper
- delegate() - Method in class io.grpc.util.OutlierDetectionLoadBalancer.EndpointTrackerMap
- delegate() - Method in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionSubchannel
- delegateFactory - Variable in class io.grpc.protobuf.services.HealthCheckingLoadBalancerFactory
- delegateFactory - Variable in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionPicker.ResultCountingClientStreamTracerFactory
- delegateListener - Variable in class io.grpc.internal.RetryingNameResolver.RetryingListener
- delegateManager - Variable in class io.grpc.util.AdvancedTlsX509TrustManager
- delegateProvider - Variable in class io.grpc.internal.AutoConfiguredLoadBalancerFactory.AutoConfiguredLoadBalancer
- delegateType() - Method in class io.grpc.util.GracefulSwitchLoadBalancer
- deliver() - Method in class io.grpc.Context.ExecutableListener
- deliver() - Method in class io.grpc.internal.MessageDeframer
-
Reads and delivers as many messages to the listener as possible.
- 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.
- DEQUE_CHUNK_SIZE - Static variable in class io.grpc.netty.WriteQueue
- deregister(LoadBalancerProvider) - Method in class io.grpc.LoadBalancerRegistry
-
Deregisters a provider.
- deregister(ManagedChannelProvider) - Method in class io.grpc.ManagedChannelRegistry
-
Deregisters a provider.
- deregister(NameResolverProvider) - Method in class io.grpc.NameResolverRegistry
-
Deregisters a provider.
- deregister(ServerProvider) - Method in class io.grpc.ServerRegistry
-
Deregisters a provider.
- description - Variable in class io.grpc.InternalChannelz.ChannelTrace.Event.Builder
- description - Variable in class io.grpc.InternalChannelz.ChannelTrace.Event
- description - Variable in class io.grpc.PartialMetricInstrument
- description - Variable in class io.grpc.Status
- description_ - Variable in class io.grpc.channelz.v1.ChannelTraceEvent.Builder
- description_ - Variable in class io.grpc.channelz.v1.ChannelTraceEvent
- DESCRIPTION_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.ChannelTraceEvent
- descriptor - Static variable in class io.grpc.binarylog.v1.BinaryLogProto
- descriptor - Static variable in class io.grpc.channelz.v1.ChannelzProto
- descriptor - Static variable in class io.grpc.health.v1.HealthProto
- descriptor - Static variable in class io.grpc.lb.v1.LoadBalancerProto
- descriptor - Static variable in class io.grpc.lookup.v1.RlsConfigProto
- descriptor - Static variable in class io.grpc.lookup.v1.RlsProto
- descriptor - Static variable in class io.grpc.reflection.v1.ServerReflectionProto
- descriptor - Static variable in class io.grpc.reflection.v1alpha.ServerReflectionProto
-
Deprecated.
- destroy() - Method in class io.grpc.servlet.GrpcServlet
- destroy() - Method in class io.grpc.servlet.jakarta.GrpcServlet
- destroy() - Method in class io.grpc.servlet.jakarta.ServletAdapter
-
Call this method when the adapter is no longer needed.
- destroy() - Method in class io.grpc.servlet.ServletAdapter
-
Call this method when the adapter is no longer needed.
- DESTROY_DELAY_SECONDS - Static variable in class io.grpc.internal.SharedResourceHolder
- destroyer - Variable in class io.grpc.internal.SharedResourceHolder
- destroyerFactory - Variable in class io.grpc.internal.SharedResourceHolder
- destroyTask - Variable in class io.grpc.internal.SharedResourceHolder.Instance
- detach() - Method in interface io.grpc.Detachable
-
Detaches the underlying data source from this instance and transfers to an
InputStream
. - detach() - Method in class io.grpc.internal.ReadableBuffers.BufferInputStream
- detach(Context) - Method in class io.grpc.Context.CancellableContext
- detach(Context) - Method in class io.grpc.Context
-
Reverse an
attach()
, restoring the previous context and exiting the current scope. - detach(Context, Context) - Method in class io.grpc.Context.Storage
-
Implements
Context.detach(io.grpc.Context)
. - detach(Context, Context) - Method in class io.grpc.ThreadLocalContextStorage
- Detachable - Interface in io.grpc
-
An extension of
InputStream
that allows the underlying data source to be detached and transferred to a new instance of the same kind. - detachAndCancel(Context, Throwable) - Method in class io.grpc.Context.CancellableContext
-
Cancel this context and detach it as the current context.
- details - Variable in class io.grpc.InternalLogId
- DetectionTimer(OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig, ChannelLogger) - Constructor for class io.grpc.util.OutlierDetectionLoadBalancer.DetectionTimer
- detectionTimerHandle - Variable in class io.grpc.util.OutlierDetectionLoadBalancer
- detectionTimerStartNanos - Variable in class io.grpc.util.OutlierDetectionLoadBalancer
- detectProxy() - Method in class io.grpc.internal.DnsNameResolver
- detectProxy(InetSocketAddress) - Method in class io.grpc.internal.ProxyDetectorImpl
- determineMetricsPickResult(LoadBalancer.PickResult) - Method in class io.grpc.rls.CachingRlsLbClient.RlsPicker
- DIRECT_ADDRESS_SCHEME - Static variable in class io.grpc.internal.ManagedChannelImplBuilder
- DirectAddressNameResolverProvider(SocketAddress, String) - Constructor for class io.grpc.internal.ManagedChannelImplBuilder.DirectAddressNameResolverProvider
- directExecutor() - Method in class io.grpc.ForwardingChannelBuilder
- directExecutor() - Method in class io.grpc.ForwardingChannelBuilder2
- directExecutor() - Method in class io.grpc.ForwardingServerBuilder
- directExecutor() - Method in class io.grpc.internal.ManagedChannelImplBuilder
- directExecutor() - Method in class io.grpc.internal.ServerImplBuilder
- 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.
- DirectExecutor() - Constructor for enum io.grpc.Context.DirectExecutor
- directServerAddress - Variable in class io.grpc.internal.ManagedChannelImplBuilder
- disable() - Method in class io.grpc.services.CallMetricRecorder
-
Turn this recorder into a no-op one.
- DISABLE_CONNECTION_HEADER_CHECK - Static variable in class io.grpc.netty.NettyServerHandler
-
Temporary workaround for #8674.
- DISABLE_SUBCHANNEL_RECONNECT_KEY - Static variable in class io.grpc.LoadBalancer
- disableAutoInboundFlowControl() - Method in class io.grpc.stub.CallStreamObserver
-
Disables automatic flow control where a token is returned to the peer after a call to the 'inbound'
StreamObserver.onNext(Object)
has completed. - disableAutoInboundFlowControl() - Method in class io.grpc.stub.ClientCalls.CallToStreamObserverAdapter
- disableAutoInboundFlowControl() - Method in class io.grpc.stub.ServerCalls.ServerCallStreamObserverImpl
- disableAutoRequest() - Method in class io.grpc.stub.ServerCalls.ServerCallStreamObserverImpl
- disableAutoRequest() - Method in class io.grpc.stub.ServerCallStreamObserver
-
Swaps to manual flow control where no message will be delivered to
StreamObserver.onNext(Object)
unless it isrequest()
ed. - disableAutoRequestWithInitial(int) - Method in class io.grpc.stub.ClientCalls.CallToStreamObserverAdapter
- disableAutoRequestWithInitial(int) - Method in class io.grpc.stub.ClientCallStreamObserver
-
Swaps to manual flow control where no message will be delivered to
StreamObserver.onNext(Object)
unless it isrequest()
ed. - disableCheckAuthority() - Method in class io.grpc.internal.ManagedChannelImplBuilder
-
Disable the check whether the authority is valid.
- disableCheckAuthority() - Method in class io.grpc.netty.NettyChannelBuilder
- disableCheckAuthority(NettyChannelBuilder) - Static method in class io.grpc.netty.InternalNettyChannelBuilder
- disabled - Variable in class io.grpc.protobuf.services.HealthCheckingLoadBalancerFactory.HealthCheckState
- disabled - Variable in class io.grpc.services.CallMetricRecorder
- disableRetry() - Method in class io.grpc.ForwardingChannelBuilder
- disableRetry() - Method in class io.grpc.ForwardingChannelBuilder2
- disableRetry() - Method in class io.grpc.internal.ManagedChannelImplBuilder
- disableRetry() - Method in class io.grpc.ManagedChannelBuilder
-
Disables the retry and hedging subsystem provided by the gRPC library.
- disableServiceConfigLookUp() - Method in class io.grpc.ForwardingChannelBuilder
- disableServiceConfigLookUp() - Method in class io.grpc.ForwardingChannelBuilder2
- disableServiceConfigLookUp() - Method in class io.grpc.internal.ManagedChannelImplBuilder
- disableServiceConfigLookUp() - Method in class io.grpc.ManagedChannelBuilder
-
Disables service config look-up from the naming system, which is enabled by default.
- discard(Attributes.Key<T>) - Method in class io.grpc.Attributes.Builder
-
Removes the key and associated value from the attributes.
- discardAll(Metadata.Key<T>) - Method in class io.grpc.Metadata
-
Remove all values for the given key without returning them.
- DISCONNECTED - Enum constant in enum io.grpc.internal.KeepAliveManager.State
- dispose() - Method in class io.grpc.internal.AbstractClientStream.GetFramer
-
Closes, without flush.
- 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.
- DnsNameResolver - Class in io.grpc.internal
-
A DNS-based
NameResolver
. - DnsNameResolver(String, String, NameResolver.Args, SharedResourceHolder.Resource<Executor>, Stopwatch, boolean) - Constructor for class io.grpc.internal.DnsNameResolver
- DnsNameResolver.AddressResolver - Interface in io.grpc.internal
-
AddressResolver resolves a hostname into a list of addresses.
- DnsNameResolver.InternalResolutionResult - Class in io.grpc.internal
-
Used as a DNS-based name resolver's internal representation of resolution result.
- DnsNameResolver.JdkAddressResolver - Enum in io.grpc.internal
- DnsNameResolver.Resolve - Class in io.grpc.internal
- DnsNameResolver.ResourceResolver - Interface in io.grpc.internal
-
DnsNameResolver.ResourceResolver
is a Dns ResourceRecord resolver. - DnsNameResolver.ResourceResolverFactory - Interface in io.grpc.internal
-
DnsNameResolver.ResourceResolverFactory
is a factory for making resource resolvers. - DnsNameResolver.SrvRecord - Class in io.grpc.internal
-
Describes a parsed SRV record.
- DnsNameResolverProvider - Class in io.grpc.internal
-
A provider for
DnsNameResolver
. - DnsNameResolverProvider() - Constructor for class io.grpc.internal.DnsNameResolverProvider
- doAttach(Context) - Method in class io.grpc.Context.Storage
-
Implements
Context.attach()
. - doAttach(Context) - Method in class io.grpc.ThreadLocalContextStorage
- doBackward(RlsProtoData.RouteLookupConfig) - Method in class io.grpc.rls.RlsProtoConverters.RouteLookupConfigConverter
- doBackward(RlsProtoData.RouteLookupRequest) - Method in class io.grpc.rls.RlsProtoConverters.RouteLookupRequestConverter
- doBackward(RlsProtoData.RouteLookupResponse) - Method in class io.grpc.rls.RlsProtoConverters.RouteLookupResponseConverter
- doExecute(Executor, Runnable) - Static method in class io.grpc.internal.Http2Ping
-
Executes the given runnable.
- doForward(RouteLookupRequest) - Method in class io.grpc.rls.RlsProtoConverters.RouteLookupRequestConverter
- doForward(RouteLookupResponse) - Method in class io.grpc.rls.RlsProtoConverters.RouteLookupResponseConverter
- doForward(Map<String, ?>) - Method in class io.grpc.rls.RlsProtoConverters.RouteLookupConfigConverter
- doGet(HttpServletRequest, HttpServletResponse) - Method in class io.grpc.servlet.jakarta.GrpcServlet
- doGet(HttpServletRequest, HttpServletResponse) - Method in class io.grpc.servlet.jakarta.ServletAdapter
-
Call this method inside
HttpServlet.doGet(HttpServletRequest, HttpServletResponse)
to serve gRPC GET request. - doGet(HttpServletRequest, HttpServletResponse) - Method in class io.grpc.servlet.GrpcServlet
- doGet(HttpServletRequest, HttpServletResponse) - Method in class io.grpc.servlet.ServletAdapter
-
Call this method inside
HttpServlet.doGet(HttpServletRequest, HttpServletResponse)
to serve gRPC GET request. - doInitialUriValidation(String) - Static method in class io.grpc.internal.SpiffeUtil
- done - Variable in class io.grpc.stub.ClientCalls.BlockingResponseStream.QueuingListener
- doPost(HttpServletRequest, HttpServletResponse) - Method in class io.grpc.servlet.jakarta.GrpcServlet
- doPost(HttpServletRequest, HttpServletResponse) - Method in class io.grpc.servlet.jakarta.ServletAdapter
-
Call this method inside
HttpServlet.doPost(HttpServletRequest, HttpServletResponse)
to serve gRPC POST request. - doPost(HttpServletRequest, HttpServletResponse) - Method in class io.grpc.servlet.GrpcServlet
- doPost(HttpServletRequest, HttpServletResponse) - Method in class io.grpc.servlet.ServletAdapter
-
Call this method inside
HttpServlet.doPost(HttpServletRequest, HttpServletResponse)
to serve gRPC POST request. - doResolve(boolean) - Method in class io.grpc.grpclb.GrpclbNameResolver
- doResolve(boolean) - Method in class io.grpc.internal.DnsNameResolver
-
Main logic of name resolution.
- DoubleCounterMetricInstrument - Class in io.grpc
-
Represents a double-valued counter metric instrument.
- DoubleCounterMetricInstrument(int, String, String, String, List<String>, List<String>, boolean) - Constructor for class io.grpc.DoubleCounterMetricInstrument
- DoubleHistogramMetricInstrument - Class in io.grpc
-
Represents a double-valued histogram metric instrument.
- DoubleHistogramMetricInstrument(int, String, String, String, List<Double>, List<String>, List<String>, boolean) - Constructor for class io.grpc.DoubleHistogramMetricInstrument
- drain() - Method in class io.grpc.SynchronizationContext
-
Run all tasks in the queue in the current thread, if no other thread is running this method.
- drain(RetriableStream.Substream) - Method in class io.grpc.internal.RetriableStream
- Drainable - Interface in io.grpc
-
Extension to an
InputStream
or alike by adding a method that transfers all content to anOutputStream
. - drainedSubstreams - Variable in class io.grpc.internal.RetriableStream.State
-
Unmodifiable collection of all the open substreams that are drained.
- drainingThread - Variable in class io.grpc.SynchronizationContext
- drainNow() - Method in class io.grpc.netty.WriteQueue
-
Executes enqueued work directly on the current thread.
- drainPendingCallbacks() - Method in class io.grpc.internal.DelayedClientCall.DelayedListener
- drainPendingCallbacks() - Method in class io.grpc.internal.DelayedStream.DelayedStreamListener
- drainPendingCalls() - Method in class io.grpc.internal.DelayedClientCall
-
Called to transition
passThrough
totrue
. - drainPendingCalls() - Method in class io.grpc.internal.DelayedStream
-
Called to transition
passThrough
totrue
. - drainTo(OutputStream) - Method in interface io.grpc.Drainable
-
Transfers the entire contents of this stream to the specified target.
- drainTo(OutputStream) - Method in class io.grpc.protobuf.lite.ProtoInputStream
- drop - Variable in class io.grpc.LoadBalancer.PickResult
- drop_ - Variable in class io.grpc.lb.v1.Server.Builder
- drop_ - Variable in class io.grpc.lb.v1.Server
- DROP_FIELD_NUMBER - Static variable in class io.grpc.lb.v1.Server
- DROP_PICK_RESULT - Static variable in class io.grpc.grpclb.GrpclbState
- DropEntry(GrpclbClientLoadRecorder, String) - Constructor for class io.grpc.grpclb.GrpclbState.DropEntry
- dropIndex - Variable in class io.grpc.grpclb.GrpclbState.RoundRobinPicker
- dropList - Variable in class io.grpc.grpclb.GrpclbState
- dropList - Variable in class io.grpc.grpclb.GrpclbState.RoundRobinPicker
- DROPPED - Enum constant in enum io.grpc.internal.ClientStreamListener.RpcProgress
-
The RPC is dropped (by load balancer).
- DropType - Enum in io.grpc.grpclb
-
The reason for dropping a request as instructed by the remote balancer.
- DropType() - Constructor for enum io.grpc.grpclb.DropType
- duration_ - Variable in class io.grpc.channelz.v1.SocketOptionLinger.Builder
- duration_ - Variable in class io.grpc.channelz.v1.SocketOptionLinger
- duration_ - Variable in class io.grpc.channelz.v1.SocketOptionTimeout.Builder
- duration_ - Variable in class io.grpc.channelz.v1.SocketOptionTimeout
- DURATION_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.SocketOptionLinger
- DURATION_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.SocketOptionTimeout
- DURATION_SECONDS_MAX - Static variable in class io.grpc.internal.JsonUtil
- DURATION_SECONDS_MIN - Static variable in class io.grpc.internal.JsonUtil
- durationBuilder_ - Variable in class io.grpc.channelz.v1.SocketOptionLinger.Builder
- durationBuilder_ - Variable in class io.grpc.channelz.v1.SocketOptionTimeout.Builder
- durationIsValid(long, int) - Static method in class io.grpc.internal.JsonUtil
-
Returns true if the given number of seconds and nanos is a valid
Duration
.
E
- eagAttributes - Variable in class io.grpc.internal.ClientTransportFactory.ClientTransportOptions
- eagAttributes - Variable in class io.grpc.netty.NettyClientHandler
- eagAttributes - Variable in class io.grpc.netty.NettyClientTransport
- eagAttributes - Variable in class io.grpc.netty.NettyServer
- eagAttributes - Variable in class io.grpc.netty.NettyServerBuilder
- eagAttributes - Variable in class io.grpc.netty.NettyServerHandler
- eagAttributes - Variable in class io.grpc.netty.NettyServerTransport
- eagAttributes(Attributes) - Method in class io.grpc.netty.NettyServerBuilder
-
Sets the EAG attributes available to protocol negotiators.
- eagAttributes(NettyServerBuilder, Attributes) - Static method in class io.grpc.netty.InternalNettyServerBuilder
-
Sets the EAG attributes available to protocol negotiators.
- effectiveDeadline() - Method in class io.grpc.internal.ClientCallImpl
- effectiveLbProvider - Variable in class io.grpc.rls.LbPolicyConfiguration.ChildLoadBalancingPolicy
- effectiveProviders - Variable in class io.grpc.LoadBalancerRegistry
- effectiveProviders - Variable in class io.grpc.ManagedChannelRegistry
-
Immutable, sorted version of
allProviders
. - effectiveProviders - Variable in class io.grpc.NameResolverRegistry
-
Generated from
allProviders
. - effectiveProviders - Variable in class io.grpc.ServerRegistry
-
Immutable, sorted version of
allProviders
. - effectiveRawChildPolicy - Variable in class io.grpc.rls.LbPolicyConfiguration.ChildLoadBalancingPolicy
- eject() - Method in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionSubchannel
- ejected - Variable in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionSubchannel
- ejectionPercentage() - Method in class io.grpc.util.OutlierDetectionLoadBalancer.EndpointTrackerMap
-
How many percent of the addresses have been ejected.
- ejectionTimeMultiplier - Variable in class io.grpc.util.OutlierDetectionLoadBalancer.EndpointTracker
- ejectionTimeNanos - Variable in class io.grpc.util.OutlierDetectionLoadBalancer.EndpointTracker
- ejectOutliers(OutlierDetectionLoadBalancer.EndpointTrackerMap, long) - Method in class io.grpc.util.OutlierDetectionLoadBalancer.FailurePercentageOutlierEjectionAlgorithm
- ejectOutliers(OutlierDetectionLoadBalancer.EndpointTrackerMap, long) - Method in interface io.grpc.util.OutlierDetectionLoadBalancer.OutlierEjectionAlgorithm
-
Eject any outlier addresses.
- ejectOutliers(OutlierDetectionLoadBalancer.EndpointTrackerMap, long) - Method in class io.grpc.util.OutlierDetectionLoadBalancer.SuccessRateOutlierEjectionAlgorithm
- ejectSubchannels(long) - Method in class io.grpc.util.OutlierDetectionLoadBalancer.EndpointTracker
- empty() - Static method in class io.grpc.internal.ManagedChannelServiceConfig
-
Returns an empty
ManagedChannelServiceConfig
. - empty() - Static method in class io.grpc.internal.ReadableBuffers
-
Returns an empty
ReadableBuffer
instance. - EMPTY - Static variable in class io.grpc.Attributes
- EMPTY - Static variable in class io.grpc.netty.GrpcHttp2OutboundHeaders
- EMPTY_BUFFER - Static variable in class io.grpc.internal.ReadableBuffers
- EMPTY_MAP - Static variable in class io.grpc.Attributes
- EMPTY_PICKER - Static variable in class io.grpc.LoadBalancer
-
Deprecated.Use
new FixedResultPicker(PickResult.withNoResult())
instead. - EMPTY_SERVICE_CONFIG - Static variable in class io.grpc.internal.ManagedChannelImpl
- emptyInstance() - Static method in class io.grpc.DecompressorRegistry
- EmptyPicker() - Constructor for class io.grpc.internal.AutoConfiguredLoadBalancerFactory.EmptyPicker
- ENABLE_ALLOCATION_TRACKING - Static variable in class io.grpc.internal.ManagedChannelOrphanWrapper.ManagedChannelReference
- enableByDefault - Variable in class io.grpc.PartialMetricInstrument
- enableCheckAuthority() - Method in class io.grpc.internal.ManagedChannelImplBuilder
-
Enable previously disabled authority check.
- enableCheckAuthority() - Method in class io.grpc.netty.NettyChannelBuilder
- enableCheckAuthority(NettyChannelBuilder) - Static method in class io.grpc.netty.InternalNettyChannelBuilder
- enabled - Variable in class io.grpc.internal.Rescheduler
- enableHappyEyeballs - Variable in class io.grpc.internal.PickFirstLeafLoadBalancer
- enableJndi - Static variable in class io.grpc.internal.DnsNameResolver
- enableJndiLocalhost - Static variable in class io.grpc.internal.DnsNameResolver
- enableNewPickFirst - Static variable in class io.grpc.internal.PickFirstLoadBalancerProvider
- enableRetry() - Method in class io.grpc.ForwardingChannelBuilder
- enableRetry() - Method in class io.grpc.ForwardingChannelBuilder2
- enableRetry() - Method in class io.grpc.internal.ManagedChannelImplBuilder
- enableRetry() - Method in class io.grpc.ManagedChannelBuilder
-
Enables the retry and hedging subsystem which will use per-method configuration.
- enableTxt - Static variable in class io.grpc.internal.DnsNameResolver
- encodeAuthority(String) - Static method in class io.grpc.internal.GrpcUtil.AuthorityEscaper
- end - Variable in class io.grpc.internal.ReadableBuffers.ByteArrayWrapper
- end - Variable in class io.grpc.InternalChannelz.RootChannelList
- end - Variable in class io.grpc.InternalChannelz.ServerList
- end - Variable in class io.grpc.InternalChannelz.ServerSocketsList
- end_ - Variable in class io.grpc.channelz.v1.GetServerSocketsResponse.Builder
- end_ - Variable in class io.grpc.channelz.v1.GetServerSocketsResponse
- end_ - Variable in class io.grpc.channelz.v1.GetServersResponse.Builder
- end_ - Variable in class io.grpc.channelz.v1.GetServersResponse
- end_ - Variable in class io.grpc.channelz.v1.GetTopChannelsResponse.Builder
- end_ - Variable in class io.grpc.channelz.v1.GetTopChannelsResponse
- END_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.GetServerSocketsResponse
- END_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.GetServersResponse
- END_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.GetTopChannelsResponse
- endNanos - Variable in class io.grpc.rls.AdaptiveThrottler.TimeBasedAccumulator.Slot
- endOfMessages() - Method in class io.grpc.internal.AbstractStream
-
Closes the underlying framer.
- endOfStream - Variable in class io.grpc.internal.AbstractServerStream.TransportState
- endOfStream() - Method in class io.grpc.netty.SendResponseHeadersCommand
- Endpoint(EquivalentAddressGroup) - Constructor for class io.grpc.util.MultiChildLoadBalancer.Endpoint
- ENDPOINT_TRACKER_KEY - Static variable in class io.grpc.util.OutlierDetectionLoadBalancer
- endpointTracker - Variable in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionSubchannel
- EndpointTracker(OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig) - Constructor for class io.grpc.util.OutlierDetectionLoadBalancer.EndpointTracker
- endpointTrackerMap - Variable in class io.grpc.util.OutlierDetectionLoadBalancer
- EndpointTrackerMap() - Constructor for class io.grpc.util.OutlierDetectionLoadBalancer.EndpointTrackerMap
- endStream - Variable in class io.grpc.netty.SendGrpcFrameCommand
- endStream() - Method in class io.grpc.netty.SendGrpcFrameCommand
- endsWith(byte[], byte[]) - Static method in class io.grpc.internal.TransportFrameUtil
-
Returns
true
ifsubject
ends withsuffix
. - enforcementPercentage - Variable in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig.FailurePercentageEjection.Builder
- enforcementPercentage - Variable in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig.FailurePercentageEjection
- enforcementPercentage - Variable in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig.SuccessRateEjection.Builder
- enforcementPercentage - Variable in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig.SuccessRateEjection
- engineGetKeyManagers() - Method in class io.grpc.netty.FixedKeyManagerFactory.FixedKeyManagerFactorySpi
- engineGetTrustManagers() - Method in class io.grpc.netty.FixedTrustManagerFactory.FixedTrustManagerFactorySpi
- engineInit(KeyStore) - Method in class io.grpc.netty.FixedTrustManagerFactory.FixedTrustManagerFactorySpi
- engineInit(KeyStore, char[]) - Method in class io.grpc.netty.FixedKeyManagerFactory.FixedKeyManagerFactorySpi
- engineInit(ManagerFactoryParameters) - Method in class io.grpc.netty.FixedKeyManagerFactory.FixedKeyManagerFactorySpi
- engineInit(ManagerFactoryParameters) - Method in class io.grpc.netty.FixedTrustManagerFactory.FixedTrustManagerFactorySpi
- ENHANCE_YOUR_CALM - Enum constant in enum io.grpc.internal.GrpcUtil.Http2Error
- enqueue(WriteQueue.QueuedCommand, boolean) - Method in class io.grpc.netty.WriteQueue
-
Enqueue a write command on the channel.
- enqueue(Runnable) - Method in class io.grpc.internal.SerializeReentrantCallsDirectExecutor
- enqueue(Runnable, boolean) - Method in class io.grpc.netty.WriteQueue
-
Enqueue the runnable.
- enqueueBuffer(ReadableBuffer) - Method in class io.grpc.internal.CompositeReadableBuffer
- ensureAlpnAndH2Enabled(ApplicationProtocolNegotiator) - Static method in class io.grpc.netty.GrpcSslContexts
- ensureCallsFinishedWithDropIsMutable() - Method in class io.grpc.lb.v1.ClientStats.Builder
- ensureChannelIsMutable() - Method in class io.grpc.channelz.v1.GetTopChannelsResponse.Builder
- ensureChannelRefIsMutable() - Method in class io.grpc.channelz.v1.Channel.Builder
- ensureChannelRefIsMutable() - Method in class io.grpc.channelz.v1.Subchannel.Builder
- ensureEntryIsMutable() - Method in class io.grpc.binarylog.v1.Metadata.Builder
- ensureEventsIsMutable() - Method in class io.grpc.channelz.v1.ChannelTrace.Builder
- ensureExtensionNumberIsMutable() - Method in class io.grpc.reflection.v1.ExtensionNumberResponse.Builder
- ensureExtensionNumberIsMutable() - Method in class io.grpc.reflection.v1alpha.ExtensionNumberResponse.Builder
- ensureFileDescriptorProtoIsMutable() - Method in class io.grpc.reflection.v1.FileDescriptorResponse.Builder
- ensureFileDescriptorProtoIsMutable() - Method in class io.grpc.reflection.v1alpha.FileDescriptorResponse.Builder
- ensureGrpcKeybuildersIsMutable() - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
- ensureHeadersIsMutable() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
- ensureHeadersIsMutable() - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
- ensureHostPatternsIsMutable() - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
- ensureHttpKeybuildersIsMutable() - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
- ensureListenSocketIsMutable() - Method in class io.grpc.channelz.v1.Server.Builder
- ensureNamesIsMutable() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
- ensureNamesIsMutable() - Method in class io.grpc.lookup.v1.NameMatcher.Builder
- ensureOptionIsMutable() - Method in class io.grpc.channelz.v1.SocketData.Builder
- ensurePathPatternsIsMutable() - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
- ensureQueryParametersIsMutable() - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
- ensureServerIsMutable() - Method in class io.grpc.channelz.v1.GetServersResponse.Builder
- ensureServersIsMutable() - Method in class io.grpc.lb.v1.ServerList.Builder
- ensureServiceIsMutable() - Method in class io.grpc.reflection.v1.ListServiceResponse.Builder
- ensureServiceIsMutable() - Method in class io.grpc.reflection.v1alpha.ListServiceResponse.Builder
- ensureSocketRefIsMutable() - Method in class io.grpc.channelz.v1.Channel.Builder
- ensureSocketRefIsMutable() - Method in class io.grpc.channelz.v1.GetServerSocketsResponse.Builder
- ensureSocketRefIsMutable() - Method in class io.grpc.channelz.v1.Subchannel.Builder
- ensureSubchannelRefIsMutable() - Method in class io.grpc.channelz.v1.Channel.Builder
- ensureSubchannelRefIsMutable() - Method in class io.grpc.channelz.v1.Subchannel.Builder
- ensureTargetsIsMutable() - Method in class io.grpc.lookup.v1.RouteLookupResponse.Builder
- ensureValidTargetsIsMutable() - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
- enterIdle() - Method in class io.grpc.internal.ForwardingManagedChannel
- enterIdle() - Method in class io.grpc.internal.ManagedChannelImpl
- enterIdle() - Method in class io.grpc.ManagedChannel
-
Invoking this method moves the channel into the IDLE state and triggers tear-down of the channel's name resolver and load balancer, while still allowing on-going RPCs on the channel to continue.
- enterIdleMode() - Method in class io.grpc.internal.ManagedChannelImpl
- enterTerminalState() - Method in class io.grpc.protobuf.services.HealthServiceImpl
- enterTerminalState() - Method in class io.grpc.protobuf.services.HealthStatusManager
-
enterTerminalState causes the health status manager to mark all services as not serving, and prevents future updates to services.
- enterTerminalState() - Method in class io.grpc.services.HealthStatusManager
-
Deprecated.enterTerminalState causes the health status manager to mark all services as not serving, and prevents future updates to services.
- entry_ - Variable in class io.grpc.binarylog.v1.Metadata.Builder
- entry_ - Variable in class io.grpc.binarylog.v1.Metadata
- ENTRY_FIELD_NUMBER - Static variable in class io.grpc.binarylog.v1.Metadata
- entryBuilder_ - Variable in class io.grpc.binarylog.v1.Metadata.Builder
- epoch - Variable in class io.grpc.internal.KeepAliveEnforcer
- EPOLL - Enum constant in enum io.grpc.netty.Utils.EventLoopGroupType
- EPOLL_DOMAIN_CLIENT_CHANNEL_TYPE - Static variable in class io.grpc.netty.Utils
- EPOLL_EVENT_LOOP_GROUP_CONSTRUCTOR - Static variable in class io.grpc.netty.Utils
- epollChannelType() - Static method in class io.grpc.netty.Utils
- epollDomainSocketChannelType() - Static method in class io.grpc.netty.Utils
- epollEventLoopGroupConstructor() - Static method in class io.grpc.netty.Utils
- epollServerChannelType() - Static method in class io.grpc.netty.Utils
- eps - Variable in class io.grpc.services.CallMetricRecorder
- eps - Variable in class io.grpc.services.MetricRecorder
- eps - Variable in class io.grpc.services.MetricReport
- equals(byte[], int, int, byte[], int, int) - Static method in class io.grpc.netty.GrpcHttp2HeadersUtils.GrpcHttp2InboundHeaders
- equals(AsciiString, byte[]) - Static method in class io.grpc.netty.GrpcHttp2HeadersUtils.GrpcHttp2InboundHeaders
- equals(AsciiString, AsciiString) - Static method in class io.grpc.netty.GrpcHttp2HeadersUtils.GrpcHttp2InboundHeaders
- equals(Object) - Method in class io.grpc.Attributes
-
Returns true if the given object is also a
Attributes
with an equal attribute values. - equals(Object) - Method in class io.grpc.binarylog.v1.Address
- equals(Object) - Method in class io.grpc.binarylog.v1.ClientHeader
- equals(Object) - Method in class io.grpc.binarylog.v1.GrpcLogEntry
- equals(Object) - Method in class io.grpc.binarylog.v1.Message
- equals(Object) - Method in class io.grpc.binarylog.v1.Metadata
- equals(Object) - Method in class io.grpc.binarylog.v1.MetadataEntry
- equals(Object) - Method in class io.grpc.binarylog.v1.ServerHeader
- equals(Object) - Method in class io.grpc.binarylog.v1.Trailer
- equals(Object) - Method in class io.grpc.channelz.v1.Address
- equals(Object) - Method in class io.grpc.channelz.v1.Address.OtherAddress
- equals(Object) - Method in class io.grpc.channelz.v1.Address.TcpIpAddress
- equals(Object) - Method in class io.grpc.channelz.v1.Address.UdsAddress
- equals(Object) - Method in class io.grpc.channelz.v1.Channel
- equals(Object) - Method in class io.grpc.channelz.v1.ChannelConnectivityState
- equals(Object) - Method in class io.grpc.channelz.v1.ChannelData
- equals(Object) - Method in class io.grpc.channelz.v1.ChannelRef
- equals(Object) - Method in class io.grpc.channelz.v1.ChannelTrace
- equals(Object) - Method in class io.grpc.channelz.v1.ChannelTraceEvent
- equals(Object) - Method in class io.grpc.channelz.v1.GetChannelRequest
- equals(Object) - Method in class io.grpc.channelz.v1.GetChannelResponse
- equals(Object) - Method in class io.grpc.channelz.v1.GetServerRequest
- equals(Object) - Method in class io.grpc.channelz.v1.GetServerResponse
- equals(Object) - Method in class io.grpc.channelz.v1.GetServerSocketsRequest
- equals(Object) - Method in class io.grpc.channelz.v1.GetServerSocketsResponse
- equals(Object) - Method in class io.grpc.channelz.v1.GetServersRequest
- equals(Object) - Method in class io.grpc.channelz.v1.GetServersResponse
- equals(Object) - Method in class io.grpc.channelz.v1.GetSocketRequest
- equals(Object) - Method in class io.grpc.channelz.v1.GetSocketResponse
- equals(Object) - Method in class io.grpc.channelz.v1.GetSubchannelRequest
- equals(Object) - Method in class io.grpc.channelz.v1.GetSubchannelResponse
- equals(Object) - Method in class io.grpc.channelz.v1.GetTopChannelsRequest
- equals(Object) - Method in class io.grpc.channelz.v1.GetTopChannelsResponse
- equals(Object) - Method in class io.grpc.channelz.v1.Security
- equals(Object) - Method in class io.grpc.channelz.v1.Security.OtherSecurity
- equals(Object) - Method in class io.grpc.channelz.v1.Security.Tls
- equals(Object) - Method in class io.grpc.channelz.v1.Server
- equals(Object) - Method in class io.grpc.channelz.v1.ServerData
- equals(Object) - Method in class io.grpc.channelz.v1.ServerRef
- equals(Object) - Method in class io.grpc.channelz.v1.Socket
- equals(Object) - Method in class io.grpc.channelz.v1.SocketData
- equals(Object) - Method in class io.grpc.channelz.v1.SocketOption
- equals(Object) - Method in class io.grpc.channelz.v1.SocketOptionLinger
- equals(Object) - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo
- equals(Object) - Method in class io.grpc.channelz.v1.SocketOptionTimeout
- equals(Object) - Method in class io.grpc.channelz.v1.SocketRef
- equals(Object) - Method in class io.grpc.channelz.v1.Subchannel
- equals(Object) - Method in class io.grpc.channelz.v1.SubchannelRef
- equals(Object) - Method in class io.grpc.ConnectivityStateInfo
- equals(Object) - Method in class io.grpc.Deadline
- equals(Object) - Method in class io.grpc.EquivalentAddressGroup
-
Returns true if the given object is also an
EquivalentAddressGroup
with an equal address list and equal attribute values. - equals(Object) - Method in class io.grpc.grpclb.GrpclbConfig
- equals(Object) - Method in class io.grpc.grpclb.GrpclbState.BackendEntry
- equals(Object) - Method in class io.grpc.grpclb.GrpclbState.DropEntry
- equals(Object) - Method in class io.grpc.grpclb.GrpclbState.ErrorEntry
- equals(Object) - Method in class io.grpc.grpclb.GrpclbState.IdleSubchannelEntry
- equals(Object) - Method in class io.grpc.grpclb.TokenAttachingTracerFactory
- equals(Object) - Method in class io.grpc.health.v1.HealthCheckRequest
- equals(Object) - Method in class io.grpc.health.v1.HealthCheckResponse
- equals(Object) - Method in class io.grpc.HttpConnectProxiedSocketAddress
- equals(Object) - Method in class io.grpc.inprocess.InProcessSocketAddress
-
Returns
true
if the object is of the same type and server names match. - equals(Object) - Method in class io.grpc.internal.ClientTransportFactory.ClientTransportOptions
- equals(Object) - Method in class io.grpc.internal.DnsNameResolver.SrvRecord
- equals(Object) - Method in class io.grpc.internal.HedgingPolicy
- equals(Object) - Method in class io.grpc.internal.ManagedChannelServiceConfig
- equals(Object) - Method in class io.grpc.internal.ManagedChannelServiceConfig.MethodInfo
- equals(Object) - Method in class io.grpc.internal.PickSubchannelArgsImpl
- equals(Object) - Method in class io.grpc.internal.RetriableStream.Throttle
- equals(Object) - Method in class io.grpc.internal.RetryPolicy
- equals(Object) - Method in class io.grpc.internal.ServerCallInfoImpl
- equals(Object) - Method in class io.grpc.internal.ServiceConfigUtil.LbConfig
- equals(Object) - Method in class io.grpc.internal.ServiceConfigUtil.PolicySelection
- equals(Object) - Method in class io.grpc.InternalChannelz.ChannelTrace.Event
- equals(Object) - Method in class io.grpc.lb.v1.ClientStats
- equals(Object) - Method in class io.grpc.lb.v1.ClientStatsPerToken
- equals(Object) - Method in class io.grpc.lb.v1.FallbackResponse
- equals(Object) - Method in class io.grpc.lb.v1.InitialLoadBalanceRequest
- equals(Object) - Method in class io.grpc.lb.v1.InitialLoadBalanceResponse
- equals(Object) - Method in class io.grpc.lb.v1.LoadBalanceRequest
- equals(Object) - Method in class io.grpc.lb.v1.LoadBalanceResponse
- equals(Object) - Method in class io.grpc.lb.v1.Server
- equals(Object) - Method in class io.grpc.lb.v1.ServerList
- equals(Object) - Method in class io.grpc.LoadBalancer.FixedResultPicker
- equals(Object) - Method in class io.grpc.LoadBalancer.PickResult
- equals(Object) - Method in class io.grpc.LoadBalancer.ResolvedAddresses
- equals(Object) - Method in class io.grpc.LoadBalancerProvider
-
Uses identity equality.
- equals(Object) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder
- equals(Object) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys
- equals(Object) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Name
- equals(Object) - Method in class io.grpc.lookup.v1.HttpKeyBuilder
- equals(Object) - Method in class io.grpc.lookup.v1.NameMatcher
- equals(Object) - Method in class io.grpc.lookup.v1.RouteLookupClusterSpecifier
- equals(Object) - Method in class io.grpc.lookup.v1.RouteLookupConfig
- equals(Object) - Method in class io.grpc.lookup.v1.RouteLookupRequest
- equals(Object) - Method in class io.grpc.lookup.v1.RouteLookupResponse
- equals(Object) - Method in class io.grpc.Metadata.Key
-
Returns true if the two objects are both Keys, and their names match (case insensitive).
- equals(Object) - Method in class io.grpc.NameResolver.ConfigOrError
- equals(Object) - Method in class io.grpc.NameResolver.ResolutionResult
-
Useful for testing.
- equals(Object) - Method in class io.grpc.netty.CancelServerStreamCommand
- equals(Object) - Method in class io.grpc.netty.ProtocolNegotiationEvent
- equals(Object) - Method in class io.grpc.netty.SendGrpcFrameCommand
- equals(Object) - Method in class io.grpc.netty.SendResponseHeadersCommand
- equals(Object) - Method in class io.grpc.reflection.v1.ErrorResponse
- equals(Object) - Method in class io.grpc.reflection.v1.ExtensionNumberResponse
- equals(Object) - Method in class io.grpc.reflection.v1.ExtensionRequest
- equals(Object) - Method in class io.grpc.reflection.v1.FileDescriptorResponse
- equals(Object) - Method in class io.grpc.reflection.v1.ListServiceResponse
- equals(Object) - Method in class io.grpc.reflection.v1.ServerReflectionRequest
- equals(Object) - Method in class io.grpc.reflection.v1.ServerReflectionResponse
- equals(Object) - Method in class io.grpc.reflection.v1.ServiceResponse
- equals(Object) - Method in class io.grpc.reflection.v1alpha.ErrorResponse
- equals(Object) - Method in class io.grpc.reflection.v1alpha.ExtensionNumberResponse
- equals(Object) - Method in class io.grpc.reflection.v1alpha.ExtensionRequest
- equals(Object) - Method in class io.grpc.reflection.v1alpha.FileDescriptorResponse
- equals(Object) - Method in class io.grpc.reflection.v1alpha.ListServiceResponse
- equals(Object) - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest
- equals(Object) - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse
- equals(Object) - Method in class io.grpc.reflection.v1alpha.ServiceResponse
- equals(Object) - Method in class io.grpc.rls.AutoValue_RlsProtoData_ExtraKeys
- equals(Object) - Method in class io.grpc.rls.AutoValue_RlsProtoData_GrpcKeyBuilder_Name
- equals(Object) - Method in class io.grpc.rls.AutoValue_RlsProtoData_GrpcKeyBuilder
- equals(Object) - Method in class io.grpc.rls.AutoValue_RlsProtoData_NameMatcher
- equals(Object) - Method in class io.grpc.rls.AutoValue_RlsProtoData_RouteLookupConfig
- equals(Object) - Method in class io.grpc.rls.AutoValue_RlsProtoData_RouteLookupRequest
- equals(Object) - Method in class io.grpc.rls.AutoValue_RlsProtoData_RouteLookupResponse
- equals(Object) - Method in class io.grpc.rls.LbPolicyConfiguration.ChildLoadBalancingPolicy
- equals(Object) - Method in class io.grpc.rls.LbPolicyConfiguration
- equals(Object) - Method in class io.grpc.rls.LinkedHashLruCache.SizedValue
- equals(Object) - Method in class io.grpc.Status
-
Equality on Statuses is not well defined.
- equals(Object) - Method in class io.grpc.StatusOr
- equals(Object) - Method in class io.grpc.util.GracefulSwitchLoadBalancer.Config
- equals(Object) - Method in class io.grpc.util.MultiChildLoadBalancer.Endpoint
- equals(Object) - Method in class io.grpc.util.RoundRobinLoadBalancer.ReadyPicker
- EquivalentAddressGroup - Class in io.grpc
-
A group of
SocketAddress
es that are considered equivalent when channel makes connections. - EquivalentAddressGroup(SocketAddress) - Constructor for class io.grpc.EquivalentAddressGroup
-
Singleton constructor without Attributes.
- EquivalentAddressGroup(SocketAddress, Attributes) - Constructor for class io.grpc.EquivalentAddressGroup
-
Singleton constructor with Attributes.
- EquivalentAddressGroup(List<SocketAddress>) - Constructor for class io.grpc.EquivalentAddressGroup
-
List constructor without
Attributes
. - EquivalentAddressGroup(List<SocketAddress>, Attributes) - Constructor for class io.grpc.EquivalentAddressGroup
-
List constructor with
Attributes
. - EquivalentAddressGroup.Attr - Annotation Type in io.grpc
-
Annotation for
EquivalentAddressGroup
's attributes. - error - Variable in class io.grpc.internal.DelayedClientCall
- error - Variable in class io.grpc.internal.DelayedStream
- error - Variable in class io.grpc.internal.DnsNameResolver.InternalResolutionResult
- error - Variable in class io.grpc.internal.FailingClientStream
- error - Variable in class io.grpc.internal.FailingClientTransport
- error - Variable in class io.grpc.LoadBalancer.ErrorPicker
-
Deprecated.
- error - Variable in class io.grpc.ManagedChannelProvider.NewChannelBuilderResult
- error - Variable in class io.grpc.netty.ProtocolNegotiators.FromChannelCredentialsResult
- error - Variable in class io.grpc.netty.ProtocolNegotiators.FromServerCredentialsResult
- error - Variable in class io.grpc.ServerProvider.NewServerBuilderResult
- error(String) - Static method in class io.grpc.ManagedChannelProvider.NewChannelBuilderResult
- error(String) - Static method in class io.grpc.netty.ProtocolNegotiators.FromChannelCredentialsResult
- error(String) - Static method in class io.grpc.netty.ProtocolNegotiators.FromServerCredentialsResult
- error(String) - Static method in class io.grpc.ServerProvider.NewServerBuilderResult
- ERROR - Enum constant in enum io.grpc.ChannelLogger.ChannelLogLevel
- ERROR - Enum constant in enum io.grpc.internal.ManagedChannelImpl.ResolutionState
- ERROR - Enum constant in enum io.grpc.rls.LruCache.EvictionType
-
Removed due to error.
- ERROR_CODE_FIELD_NUMBER - Static variable in class io.grpc.reflection.v1.ErrorResponse
- ERROR_CODE_FIELD_NUMBER - Static variable in class io.grpc.reflection.v1alpha.ErrorResponse
- ERROR_MESSAGE_FIELD_NUMBER - Static variable in class io.grpc.reflection.v1.ErrorResponse
- ERROR_MESSAGE_FIELD_NUMBER - Static variable in class io.grpc.reflection.v1alpha.ErrorResponse
- ERROR_MSG - Static variable in class io.grpc.util.TransmitStatusRuntimeExceptionInterceptor.SerializingServerCall
- ERROR_RESPONSE - Enum constant in enum io.grpc.reflection.v1.ServerReflectionResponse.MessageResponseCase
- ERROR_RESPONSE - Enum constant in enum io.grpc.reflection.v1alpha.ServerReflectionResponse.MessageResponseCase
- ERROR_RESPONSE_FIELD_NUMBER - Static variable in class io.grpc.reflection.v1.ServerReflectionResponse
- ERROR_RESPONSE_FIELD_NUMBER - Static variable in class io.grpc.reflection.v1alpha.ServerReflectionResponse
- errorCharset - Variable in class io.grpc.internal.Http2ClientStreamTransportState
- errorCode_ - Variable in class io.grpc.reflection.v1.ErrorResponse.Builder
- errorCode_ - Variable in class io.grpc.reflection.v1.ErrorResponse
- errorCode_ - Variable in class io.grpc.reflection.v1alpha.ErrorResponse.Builder
- errorCode_ - Variable in class io.grpc.reflection.v1alpha.ErrorResponse
- ErrorEntry(Status) - Constructor for class io.grpc.grpclb.GrpclbState.ErrorEntry
- errorMessage_ - Variable in class io.grpc.reflection.v1.ErrorResponse.Builder
- errorMessage_ - Variable in class io.grpc.reflection.v1.ErrorResponse
- errorMessage_ - Variable in class io.grpc.reflection.v1alpha.ErrorResponse.Builder
- errorMessage_ - Variable in class io.grpc.reflection.v1alpha.ErrorResponse
- ErrorPicker(Status) - Constructor for class io.grpc.LoadBalancer.ErrorPicker
-
Deprecated.
- ErrorResponse - Class in io.grpc.reflection.v1
-
The error code and error message sent by the server when an error occurs.
- ErrorResponse - Class in io.grpc.reflection.v1alpha
-
The error code and error message sent by the server when an error occurs.
- ErrorResponse() - Constructor for class io.grpc.reflection.v1.ErrorResponse
- ErrorResponse() - Constructor for class io.grpc.reflection.v1alpha.ErrorResponse
- ErrorResponse(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.reflection.v1.ErrorResponse
- ErrorResponse(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.reflection.v1alpha.ErrorResponse
- ErrorResponse.Builder - Class in io.grpc.reflection.v1
-
The error code and error message sent by the server when an error occurs.
- ErrorResponse.Builder - Class in io.grpc.reflection.v1alpha
-
The error code and error message sent by the server when an error occurs.
- errorResponseBuilder_ - Variable in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
- errorResponseBuilder_ - Variable in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
- ErrorResponseOrBuilder - Interface in io.grpc.reflection.v1
- ErrorResponseOrBuilder - Interface in io.grpc.reflection.v1alpha
- estimatedMaxSizeBytes - Variable in class io.grpc.rls.LinkedHashLruCache
- estimatedMaxSizeBytes() - Method in class io.grpc.rls.LinkedHashLruCache
- estimatedSize() - Method in class io.grpc.rls.LinkedHashLruCache
- estimatedSize() - Method in interface io.grpc.rls.LruCache
-
Returns the estimated number of entry of the cache.
- estimatedSizeBytes - Variable in class io.grpc.rls.LinkedHashLruCache
- estimatedSizeBytes() - Method in class io.grpc.rls.LinkedHashLruCache
-
Returns estimated cache size bytes.
- estimateSizeOf(RlsProtoData.RouteLookupRequest, CachingRlsLbClient.CacheEntry) - Method in class io.grpc.rls.CachingRlsLbClient.RlsAsyncLruCache
- estimateSizeOf(K, V) - Method in class io.grpc.rls.LinkedHashLruCache
-
Returns estimated size of entry to keep track.
- Event(String, InternalChannelz.ChannelTrace.Event.Severity, long, InternalWithLogId, InternalWithLogId) - Constructor for class io.grpc.InternalChannelz.ChannelTrace.Event
- EVENT_TYPE_CANCEL - Enum constant in enum io.grpc.binarylog.v1.GrpcLogEntry.EventType
-
A signal that the RPC is cancelled.
- EVENT_TYPE_CANCEL_VALUE - Static variable in enum io.grpc.binarylog.v1.GrpcLogEntry.EventType
-
A signal that the RPC is cancelled.
- EVENT_TYPE_CLIENT_HALF_CLOSE - Enum constant in enum io.grpc.binarylog.v1.GrpcLogEntry.EventType
-
A signal that client is done sending
- EVENT_TYPE_CLIENT_HALF_CLOSE_VALUE - Static variable in enum io.grpc.binarylog.v1.GrpcLogEntry.EventType
-
A signal that client is done sending
- EVENT_TYPE_CLIENT_HEADER - Enum constant in enum io.grpc.binarylog.v1.GrpcLogEntry.EventType
-
Header sent from client to server
- EVENT_TYPE_CLIENT_HEADER_VALUE - Static variable in enum io.grpc.binarylog.v1.GrpcLogEntry.EventType
-
Header sent from client to server
- EVENT_TYPE_CLIENT_MESSAGE - Enum constant in enum io.grpc.binarylog.v1.GrpcLogEntry.EventType
-
Message sent from client to server
- EVENT_TYPE_CLIENT_MESSAGE_VALUE - Static variable in enum io.grpc.binarylog.v1.GrpcLogEntry.EventType
-
Message sent from client to server
- EVENT_TYPE_SERVER_HEADER - Enum constant in enum io.grpc.binarylog.v1.GrpcLogEntry.EventType
-
Header sent from server to client
- EVENT_TYPE_SERVER_HEADER_VALUE - Static variable in enum io.grpc.binarylog.v1.GrpcLogEntry.EventType
-
Header sent from server to client
- EVENT_TYPE_SERVER_MESSAGE - Enum constant in enum io.grpc.binarylog.v1.GrpcLogEntry.EventType
-
Message sent from server to client
- EVENT_TYPE_SERVER_MESSAGE_VALUE - Static variable in enum io.grpc.binarylog.v1.GrpcLogEntry.EventType
-
Message sent from server to client
- EVENT_TYPE_SERVER_TRAILER - Enum constant in enum io.grpc.binarylog.v1.GrpcLogEntry.EventType
-
Trailer indicates the end of the RPC.
- EVENT_TYPE_SERVER_TRAILER_VALUE - Static variable in enum io.grpc.binarylog.v1.GrpcLogEntry.EventType
-
Trailer indicates the end of the RPC.
- EVENT_TYPE_UNKNOWN - Enum constant in enum io.grpc.binarylog.v1.GrpcLogEntry.EventType
-
EVENT_TYPE_UNKNOWN = 0;
- EVENT_TYPE_UNKNOWN_VALUE - Static variable in enum io.grpc.binarylog.v1.GrpcLogEntry.EventType
-
EVENT_TYPE_UNKNOWN = 0;
- eventLoop - Variable in class io.grpc.netty.NettyClientStream.TransportState
- eventLoop - Variable in class io.grpc.netty.NettyServerStream.TransportState
- eventLoopGroup(EventLoopGroup) - Method in class io.grpc.netty.NettyChannelBuilder
-
Provides an EventGroupLoop to be used by the netty transport.
- eventLoopGroupPool - Variable in class io.grpc.netty.NettyChannelBuilder
- eventLoopGroupPool(ObjectPool<? extends EventLoopGroup>) - Method in class io.grpc.netty.NettyChannelBuilder
- eventLoopGroupType - Variable in class io.grpc.netty.Utils.DefaultEventLoopGroupResource
- EventLoopGroupType() - Constructor for enum io.grpc.netty.Utils.EventLoopGroupType
- events - Variable in class io.grpc.internal.ChannelTracer
- events - Variable in class io.grpc.InternalChannelz.ChannelTrace.Builder
- events - Variable in class io.grpc.InternalChannelz.ChannelTrace
- events_ - Variable in class io.grpc.channelz.v1.ChannelTrace.Builder
- events_ - Variable in class io.grpc.channelz.v1.ChannelTrace
- EVENTS_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.ChannelTrace
- eventsBuilder_ - Variable in class io.grpc.channelz.v1.ChannelTrace.Builder
- eventsLogged - Variable in class io.grpc.internal.ChannelTracer
- EventType(int) - Constructor for enum io.grpc.binarylog.v1.GrpcLogEntry.EventType
- evictionListener - Variable in class io.grpc.rls.CachingRlsLbClient.Builder
- evictionListener - Variable in class io.grpc.rls.LinkedHashLruCache
- EvictionType() - Constructor for enum io.grpc.rls.LruCache.EvictionType
- exceptionCaught(ChannelHandlerContext, Throwable) - Method in class io.grpc.netty.AbstractNettyHandler
- exceptionCaught(ChannelHandlerContext, Throwable) - Method in class io.grpc.netty.WriteBufferingAndExceptionHandler
- exceptionStatus - Variable in class io.grpc.internal.ClientCallImpl.ClientStreamListenerImpl
- exceptionThrown(Status) - Method in class io.grpc.internal.ClientCallImpl.ClientStreamListenerImpl
-
Cancels call and schedules onClose() notification.
- ExecutableListener(Executor, Context.CancellationListener, Context) - Constructor for class io.grpc.Context.ExecutableListener
- execute(CompositeReadableBuffer.ReadOperation<T>, int, T, int) - Method in class io.grpc.internal.CompositeReadableBuffer
-
Executes the given
CompositeReadableBuffer.ReadOperation
against theReadableBuffer
s required to satisfy the requestedlength
. - execute(Runnable) - Method in enum io.grpc.Context.DirectExecutor
- execute(Runnable) - Method in class io.grpc.internal.ManagedChannelImpl.ExecutorHolder
- execute(Runnable) - Method in class io.grpc.internal.ManagedChannelImpl.RestrictedScheduledExecutor
- execute(Runnable) - Method in class io.grpc.internal.SerializeReentrantCallsDirectExecutor
- execute(Runnable) - Method in class io.grpc.internal.SerializingExecutor
-
Runs the given runnable strictly after all Runnables that were submitted before it, and using the
executor
passed to the constructor. - execute(Runnable) - Method in class io.grpc.stub.ClientCalls.ThreadlessExecutor
- execute(Runnable) - Method in class io.grpc.SynchronizationContext
-
Adds a task and run it in this synchronization context as soon as possible.
- executeCloseObserverInContext(ClientCall.Listener<RespT>, Status) - Method in class io.grpc.internal.ManagedChannelImpl.ConfigSelectingClientCall
- executeLater(Runnable) - Method in class io.grpc.SynchronizationContext
-
Adds a task that will be run when
SynchronizationContext.drain()
is called. - executeNoThrow(CompositeReadableBuffer.NoThrowReadOperation<T>, int, T, int) - Method in class io.grpc.internal.CompositeReadableBuffer
- executing - Variable in class io.grpc.internal.SerializeReentrantCallsDirectExecutor
- executor - Variable in class io.grpc.CallOptions.Builder
- executor - Variable in class io.grpc.CallOptions
- executor - Variable in class io.grpc.Context.ExecutableListener
- executor - Variable in class io.grpc.internal.ConnectivityStateManager.Listener
- executor - Variable in class io.grpc.internal.DnsNameResolver
- executor - Variable in class io.grpc.internal.ManagedChannelImpl
- executor - Variable in class io.grpc.internal.ManagedChannelImpl.ExecutorHolder
- executor - Variable in class io.grpc.internal.OobChannel
- executor - Variable in class io.grpc.internal.SerializingExecutor
-
Underlying executor that all submitted Runnable objects are run on.
- executor - Variable in class io.grpc.internal.ServerImpl
-
Executor for application processing.
- executor - Variable in class io.grpc.internal.SubchannelChannel
- executor - Variable in class io.grpc.NameResolver.Args.Builder
- executor - Variable in class io.grpc.NameResolver.Args
- executor - Variable in class io.grpc.netty.ProtocolNegotiators.ClientTlsHandler
- executor - Variable in class io.grpc.netty.ProtocolNegotiators.ClientTlsProtocolNegotiator
- executor - Variable in class io.grpc.netty.ProtocolNegotiators.ServerTlsHandler
- executor - Variable in class io.grpc.netty.SendPingCommand
- executor() - Method in class io.grpc.netty.SendPingCommand
- executor(Executor) - Method in class io.grpc.ForwardingChannelBuilder
- executor(Executor) - Method in class io.grpc.ForwardingChannelBuilder2
- executor(Executor) - Method in class io.grpc.ForwardingServerBuilder
- executor(Executor) - Method in class io.grpc.internal.ManagedChannelImplBuilder
- executor(Executor) - Method in class io.grpc.internal.ServerImplBuilder
- executor(Executor) - Method in class io.grpc.ManagedChannelBuilder
-
Provides a custom executor.
- executor(Executor) - Method in class io.grpc.ServerBuilder
-
Provides a custom executor.
- ExecutorHolder(ObjectPool<? extends Executor>) - Constructor for class io.grpc.internal.ManagedChannelImpl.ExecutorHolder
- executorPool - Variable in class io.grpc.internal.ManagedChannelImpl
- executorPool - Variable in class io.grpc.internal.ManagedChannelImplBuilder
- executorPool - Variable in class io.grpc.internal.OobChannel
- executorPool - Variable in class io.grpc.internal.ServerImpl
- executorPool - Variable in class io.grpc.internal.ServerImplBuilder
- executorPool - Variable in class io.grpc.netty.ProtocolNegotiators.ClientTlsProtocolNegotiator
- executorResource - Variable in class io.grpc.internal.DnsNameResolver
-
Executor that will be used if an Executor is not provide via
NameResolver.Args
. - executorSupplier - Variable in class io.grpc.internal.ServerImpl
- executorSupplier - Variable in class io.grpc.internal.ServerImplBuilder
- exhaust(InputStream) - Static method in class io.grpc.internal.GrpcUtil
-
Reads
in
until end of stream. - EXHAUSTED_STREAMS_STATUS - Static variable in class io.grpc.netty.NettyClientHandler
-
Status used when the transport has exhausted the number of streams.
- exitIdleMode() - Method in class io.grpc.internal.ManagedChannelImpl
-
Make the channel exit idle mode, if it's in it.
- expand(int) - Method in class io.grpc.Metadata
- expandHeadersAndValues() - Method in class io.grpc.netty.GrpcHttp2HeadersUtils.GrpcHttp2InboundHeaders
- expectedGzipTrailerIsize - Variable in class io.grpc.internal.GzipInflatingBuffer
- expectUpdates() - Method in class io.grpc.internal.ServiceConfigState
- ExperimentalApi - Annotation Type in io.grpc
-
Indicates a public API that can change at any time, and has no guarantee of API stability and backward-compatibility.
- expired - Variable in class io.grpc.Deadline
- EXPIRED - Enum constant in enum io.grpc.rls.LruCache.EvictionType
-
Evicted due to entry expired.
- expireTime - Variable in class io.grpc.rls.CachingRlsLbClient.DataCacheEntry
- EXPLICIT - Enum constant in enum io.grpc.rls.LruCache.EvictionType
-
Explicitly removed by user.
- ExponentialBackoffPolicy - Class in io.grpc.internal
-
Retry Policy for Transport reconnection.
- ExponentialBackoffPolicy() - Constructor for class io.grpc.internal.ExponentialBackoffPolicy
- ExponentialBackoffPolicy.Provider - Class in io.grpc.internal
- EXTENSION_NUMBER_FIELD_NUMBER - Static variable in class io.grpc.reflection.v1.ExtensionNumberResponse
- EXTENSION_NUMBER_FIELD_NUMBER - Static variable in class io.grpc.reflection.v1.ExtensionRequest
- EXTENSION_NUMBER_FIELD_NUMBER - Static variable in class io.grpc.reflection.v1alpha.ExtensionNumberResponse
- EXTENSION_NUMBER_FIELD_NUMBER - Static variable in class io.grpc.reflection.v1alpha.ExtensionRequest
- extensionNumber_ - Variable in class io.grpc.reflection.v1.ExtensionNumberResponse.Builder
- extensionNumber_ - Variable in class io.grpc.reflection.v1.ExtensionNumberResponse
- extensionNumber_ - Variable in class io.grpc.reflection.v1.ExtensionRequest.Builder
- extensionNumber_ - Variable in class io.grpc.reflection.v1.ExtensionRequest
- extensionNumber_ - Variable in class io.grpc.reflection.v1alpha.ExtensionNumberResponse.Builder
- extensionNumber_ - Variable in class io.grpc.reflection.v1alpha.ExtensionNumberResponse
- extensionNumber_ - Variable in class io.grpc.reflection.v1alpha.ExtensionRequest.Builder
- extensionNumber_ - Variable in class io.grpc.reflection.v1alpha.ExtensionRequest
- extensionNumberMemoizedSerializedSize - Variable in class io.grpc.reflection.v1.ExtensionNumberResponse
- extensionNumberMemoizedSerializedSize - Variable in class io.grpc.reflection.v1alpha.ExtensionNumberResponse
- ExtensionNumberResponse - Class in io.grpc.reflection.v1
-
A list of extension numbers sent by the server answering all_extension_numbers_of_type request.
- ExtensionNumberResponse - Class in io.grpc.reflection.v1alpha
-
A list of extension numbers sent by the server answering all_extension_numbers_of_type request.
- ExtensionNumberResponse() - Constructor for class io.grpc.reflection.v1.ExtensionNumberResponse
- ExtensionNumberResponse() - Constructor for class io.grpc.reflection.v1alpha.ExtensionNumberResponse
- ExtensionNumberResponse(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.reflection.v1.ExtensionNumberResponse
- ExtensionNumberResponse(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.reflection.v1alpha.ExtensionNumberResponse
- ExtensionNumberResponse.Builder - Class in io.grpc.reflection.v1
-
A list of extension numbers sent by the server answering all_extension_numbers_of_type request.
- ExtensionNumberResponse.Builder - Class in io.grpc.reflection.v1alpha
-
A list of extension numbers sent by the server answering all_extension_numbers_of_type request.
- ExtensionNumberResponseOrBuilder - Interface in io.grpc.reflection.v1
- ExtensionNumberResponseOrBuilder - Interface in io.grpc.reflection.v1alpha
- ExtensionRequest - Class in io.grpc.reflection.v1
-
The type name and extension number sent by the client when requesting file_containing_extension.
- ExtensionRequest - Class in io.grpc.reflection.v1alpha
-
The type name and extension number sent by the client when requesting file_containing_extension.
- ExtensionRequest() - Constructor for class io.grpc.reflection.v1.ExtensionRequest
- ExtensionRequest() - Constructor for class io.grpc.reflection.v1alpha.ExtensionRequest
- ExtensionRequest(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.reflection.v1.ExtensionRequest
- ExtensionRequest(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.reflection.v1alpha.ExtensionRequest
- ExtensionRequest.Builder - Class in io.grpc.reflection.v1
-
The type name and extension number sent by the client when requesting file_containing_extension.
- ExtensionRequest.Builder - Class in io.grpc.reflection.v1alpha
-
The type name and extension number sent by the client when requesting file_containing_extension.
- ExtensionRequestOrBuilder - Interface in io.grpc.reflection.v1
- ExtensionRequestOrBuilder - Interface in io.grpc.reflection.v1alpha
- EXTRA_KEY_NAMES - Static variable in class io.grpc.rls.RlsProtoConverters
- EXTRA_KEYS_FIELD_NUMBER - Static variable in class io.grpc.lookup.v1.GrpcKeyBuilder
- extractBareMethodName(String) - Static method in class io.grpc.MethodDescriptor
-
Extract the method name out of a fully qualified method name.
- extractCert(List<Map<String, ?>>, String) - Static method in class io.grpc.internal.SpiffeUtil
- extractChannelData(InternalChannelz.ChannelStats) - Static method in class io.grpc.protobuf.services.ChannelzProtoUtil
- extractCharset(Metadata) - Static method in class io.grpc.internal.Http2ClientStreamTransportState
-
Inspect the raw metadata and figure out what charset is being used.
- extractFullServiceName(String) - Static method in class io.grpc.MethodDescriptor
-
Extract the fully qualified service name out of a fully qualified method name.
- extractSocketData(InternalChannelz.SocketStats) - Static method in class io.grpc.protobuf.services.ChannelzProtoUtil
- extractSpiffeId(X509Certificate[]) - Static method in class io.grpc.internal.SpiffeUtil
-
Returns the SPIFFE ID from the leaf certificate, if present.
- extraHeaders - Variable in class io.grpc.stub.MetadataUtils.HeaderAttachingClientInterceptor
- extraKeys - Variable in class io.grpc.rls.AutoValue_RlsProtoData_GrpcKeyBuilder
- extraKeys() - Method in class io.grpc.rls.AutoValue_RlsProtoData_GrpcKeyBuilder
- extraKeys() - Method in class io.grpc.rls.RlsProtoData.GrpcKeyBuilder
- ExtraKeys() - Constructor for class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys
- ExtraKeys() - Constructor for class io.grpc.rls.RlsProtoData.ExtraKeys
- ExtraKeys(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys
- extraKeys_ - Variable in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
- extraKeys_ - Variable in class io.grpc.lookup.v1.GrpcKeyBuilder
- extraKeysBuilder_ - Variable in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
- extras - Variable in class io.grpc.stub.MetadataUtils.MetadataAttachingServerInterceptor
F
- fackets - Variable in class io.grpc.InternalChannelz.TcpInfo.Builder
- fackets - Variable in class io.grpc.InternalChannelz.TcpInfo
- factory - Variable in class io.grpc.internal.ManagedChannelImplBuilder.InterceptorFactoryWrapper
- factory - Variable in class io.grpc.internal.NameResolverFactoryToProviderFacade
- factory - Variable in class io.grpc.NameResolverRegistry
- factory - Variable in class io.grpc.protobuf.services.BinaryLogProviderImpl
- Factory() - Constructor for class io.grpc.ClientStreamTracer.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
- Factory(TimeProvider) - Constructor for class io.grpc.internal.TransportTracer.Factory
- FactoryImpl(BinaryLogSink, String) - Constructor for class io.grpc.protobuf.services.BinlogHelper.FactoryImpl
-
Accepts a string in the format specified by the binary log spec.
- fail(Status) - Method in class io.grpc.CallCredentials.MetadataApplier
-
Called when there has been an error when preparing the headers.
- fail(Status) - Method in class io.grpc.CompositeCallCredentials.CombiningMetadataApplier
- fail(Status) - Method in class io.grpc.CompositeCallCredentials.WrappingMetadataApplier
- fail(Status) - Method in class io.grpc.internal.MetadataApplierImpl
- failCause - Variable in class io.grpc.netty.WriteBufferingAndExceptionHandler
- failed(Throwable) - Method in class io.grpc.internal.Http2Ping
-
Completes this operation exceptionally.
- FAILED_PICKS_COUNTER - Static variable in class io.grpc.rls.CachingRlsLbClient
- FAILED_PRECONDITION - Enum constant in enum io.grpc.Status.Code
-
Operation was rejected because the system is not in a state required for the operation's execution.
- 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.
- failedClientStream(StatsTraceContext, Status) - Method in class io.grpc.inprocess.InProcessTransport
- FailingClientStream - Class in io.grpc.internal
-
An implementation of
ClientStream
that fails (by callingClientStreamListener.closed(io.grpc.Status, io.grpc.internal.ClientStreamListener.RpcProgress, io.grpc.Metadata)
) when started, and silently does nothing for the other operations. - FailingClientStream(Status, ClientStreamTracer[]) - Constructor for class io.grpc.internal.FailingClientStream
-
Creates a
FailingClientStream
that would fail with the given error. - FailingClientStream(Status, ClientStreamListener.RpcProgress, ClientStreamTracer[]) - Constructor for class io.grpc.internal.FailingClientStream
-
Creates a
FailingClientStream
that would fail with the given error. - FailingClientTransport - Class in io.grpc.internal
-
A client transport that creates streams that will immediately fail when started.
- FailingClientTransport(Status, ClientStreamListener.RpcProgress) - Constructor for class io.grpc.internal.FailingClientTransport
- FailingPicker(Status) - Constructor for class io.grpc.internal.AutoConfiguredLoadBalancerFactory.FailingPicker
- failure - Variable in class io.grpc.internal.AutoConfiguredLoadBalancerFactory.FailingPicker
- failureCause - Variable in class io.grpc.internal.Http2Ping
-
If non-null, indicates the ping failed.
- failureCount - Variable in class io.grpc.util.OutlierDetectionLoadBalancer.EndpointTracker.CallCounter
- failurePercentageEjection - Variable in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig.Builder
- failurePercentageEjection - Variable in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig
- FailurePercentageEjection(Integer, Integer, Integer, Integer) - Constructor for class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig.FailurePercentageEjection
- FailurePercentageOutlierEjectionAlgorithm(OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig, ChannelLogger) - Constructor for class io.grpc.util.OutlierDetectionLoadBalancer.FailurePercentageOutlierEjectionAlgorithm
- failureRate() - Method in class io.grpc.util.OutlierDetectionLoadBalancer.EndpointTracker
- failWrites(Throwable) - Method in class io.grpc.netty.WriteBufferingAndExceptionHandler
-
Propagate failures to all buffered writes.
- FAKE - Enum constant in enum io.grpc.TlsChannelCredentials.Feature
-
A feature that no consumer should understand.
- FAKE - Enum constant in enum io.grpc.TlsServerCredentials.Feature
-
A feature that no consumer should understand.
- fakeFeature - Variable in class io.grpc.TlsChannelCredentials.Builder
- fakeFeature - Variable in class io.grpc.TlsChannelCredentials
- fakeFeature - Variable in class io.grpc.TlsServerCredentials.Builder
- fakeFeature - Variable in class io.grpc.TlsServerCredentials
- FALLBACK_RESPONSE - Enum constant in enum io.grpc.lb.v1.LoadBalanceResponse.LoadBalanceResponseTypeCase
- FALLBACK_RESPONSE_FIELD_NUMBER - Static variable in class io.grpc.lb.v1.LoadBalanceResponse
- FALLBACK_TIMEOUT_MS - Static variable in class io.grpc.grpclb.GrpclbState
- fallbackBackendList - Variable in class io.grpc.grpclb.GrpclbState
- fallbackChildPolicyWrapper - Variable in class io.grpc.rls.CachingRlsLbClient.RlsPicker
- fallbackHandlerRegistry(HandlerRegistry) - Method in class io.grpc.ForwardingServerBuilder
- fallbackHandlerRegistry(HandlerRegistry) - Method in class io.grpc.internal.ServerImplBuilder
- 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.
- FallbackModeTask(Status) - Constructor for class io.grpc.grpclb.GrpclbState.FallbackModeTask
- fallbackReason - Variable in class io.grpc.grpclb.GrpclbState
- fallbackRegistry - Variable in class io.grpc.internal.ServerImpl
- fallbackRegistry - Variable in class io.grpc.internal.ServerImplBuilder
- FallbackResponse - Class in io.grpc.lb.v1
-
Protobuf type
grpc.lb.v1.FallbackResponse
- FallbackResponse() - Constructor for class io.grpc.lb.v1.FallbackResponse
- FallbackResponse(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.lb.v1.FallbackResponse
- FallbackResponse.Builder - Class in io.grpc.lb.v1
-
Protobuf type
grpc.lb.v1.FallbackResponse
- fallbackResponseBuilder_ - Variable in class io.grpc.lb.v1.LoadBalanceResponse.Builder
- FallbackResponseOrBuilder - Interface in io.grpc.lb.v1
- fallbackTimeoutMs - Variable in class io.grpc.grpclb.GrpclbConfig
- fallbackTimeoutMs - Variable in class io.grpc.grpclb.GrpclbState
- fallbackTimer - Variable in class io.grpc.grpclb.GrpclbState
- Feature() - Constructor for enum io.grpc.TlsChannelCredentials.Feature
- Feature() - Constructor for enum io.grpc.TlsServerCredentials.Feature
- FieldUpdaterAtomicHelper(AtomicIntegerFieldUpdater<SerializingExecutor>) - Constructor for class io.grpc.internal.SerializingExecutor.FieldUpdaterAtomicHelper
- file - Variable in class io.grpc.util.AdvancedTlsX509TrustManager.LoadFilePathExecution
- FILE_BY_FILENAME - Enum constant in enum io.grpc.reflection.v1.ServerReflectionRequest.MessageRequestCase
- FILE_BY_FILENAME - Enum constant in enum io.grpc.reflection.v1alpha.ServerReflectionRequest.MessageRequestCase
- FILE_BY_FILENAME_FIELD_NUMBER - Static variable in class io.grpc.reflection.v1.ServerReflectionRequest
- FILE_BY_FILENAME_FIELD_NUMBER - Static variable in class io.grpc.reflection.v1alpha.ServerReflectionRequest
- FILE_CONTAINING_EXTENSION - Enum constant in enum io.grpc.reflection.v1.ServerReflectionRequest.MessageRequestCase
- FILE_CONTAINING_EXTENSION - Enum constant in enum io.grpc.reflection.v1alpha.ServerReflectionRequest.MessageRequestCase
- FILE_CONTAINING_EXTENSION_FIELD_NUMBER - Static variable in class io.grpc.reflection.v1.ServerReflectionRequest
- FILE_CONTAINING_EXTENSION_FIELD_NUMBER - Static variable in class io.grpc.reflection.v1alpha.ServerReflectionRequest
- FILE_CONTAINING_SYMBOL - Enum constant in enum io.grpc.reflection.v1.ServerReflectionRequest.MessageRequestCase
- FILE_CONTAINING_SYMBOL - Enum constant in enum io.grpc.reflection.v1alpha.ServerReflectionRequest.MessageRequestCase
- FILE_CONTAINING_SYMBOL_FIELD_NUMBER - Static variable in class io.grpc.reflection.v1.ServerReflectionRequest
- FILE_CONTAINING_SYMBOL_FIELD_NUMBER - Static variable in class io.grpc.reflection.v1alpha.ServerReflectionRequest
- FILE_DESCRIPTOR_PROTO_FIELD_NUMBER - Static variable in class io.grpc.reflection.v1.FileDescriptorResponse
- FILE_DESCRIPTOR_PROTO_FIELD_NUMBER - Static variable in class io.grpc.reflection.v1alpha.FileDescriptorResponse
- FILE_DESCRIPTOR_RESPONSE - Enum constant in enum io.grpc.reflection.v1.ServerReflectionResponse.MessageResponseCase
- FILE_DESCRIPTOR_RESPONSE - Enum constant in enum io.grpc.reflection.v1alpha.ServerReflectionResponse.MessageResponseCase
- FILE_DESCRIPTOR_RESPONSE_FIELD_NUMBER - Static variable in class io.grpc.reflection.v1.ServerReflectionResponse
- FILE_DESCRIPTOR_RESPONSE_FIELD_NUMBER - Static variable in class io.grpc.reflection.v1alpha.ServerReflectionResponse
- fileContainingExtensionBuilder_ - Variable in class io.grpc.reflection.v1.ServerReflectionRequest.Builder
- fileContainingExtensionBuilder_ - Variable in class io.grpc.reflection.v1alpha.ServerReflectionRequest.Builder
- FileDescriptorIndex(List<ServerServiceDefinition>) - Constructor for class io.grpc.protobuf.services.ProtoReflectionServiceV1.FileDescriptorIndex
- fileDescriptorProto_ - Variable in class io.grpc.reflection.v1.FileDescriptorResponse.Builder
- fileDescriptorProto_ - Variable in class io.grpc.reflection.v1.FileDescriptorResponse
- fileDescriptorProto_ - Variable in class io.grpc.reflection.v1alpha.FileDescriptorResponse.Builder
- fileDescriptorProto_ - Variable in class io.grpc.reflection.v1alpha.FileDescriptorResponse
- FileDescriptorResponse - Class in io.grpc.reflection.v1
-
Serialized FileDescriptorProto messages sent by the server answering a file_by_filename, file_containing_symbol, or file_containing_extension request.
- FileDescriptorResponse - Class in io.grpc.reflection.v1alpha
-
Serialized FileDescriptorProto messages sent by the server answering a file_by_filename, file_containing_symbol, or file_containing_extension request.
- FileDescriptorResponse() - Constructor for class io.grpc.reflection.v1.FileDescriptorResponse
- FileDescriptorResponse() - Constructor for class io.grpc.reflection.v1alpha.FileDescriptorResponse
- FileDescriptorResponse(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.reflection.v1.FileDescriptorResponse
- FileDescriptorResponse(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.reflection.v1alpha.FileDescriptorResponse
- FileDescriptorResponse.Builder - Class in io.grpc.reflection.v1
-
Serialized FileDescriptorProto messages sent by the server answering a file_by_filename, file_containing_symbol, or file_containing_extension request.
- FileDescriptorResponse.Builder - Class in io.grpc.reflection.v1alpha
-
Serialized FileDescriptorProto messages sent by the server answering a file_by_filename, file_containing_symbol, or file_containing_extension request.
- fileDescriptorResponseBuilder_ - Variable in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
- fileDescriptorResponseBuilder_ - Variable in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
- FileDescriptorResponseOrBuilder - Interface in io.grpc.reflection.v1
- FileDescriptorResponseOrBuilder - Interface in io.grpc.reflection.v1alpha
- fileDescriptorsByExtensionAndNumber - Variable in class io.grpc.protobuf.services.ProtoReflectionServiceV1.FileDescriptorIndex
- fileDescriptorsByName - Variable in class io.grpc.protobuf.services.ProtoReflectionServiceV1.FileDescriptorIndex
- fileDescriptorsBySymbol - Variable in class io.grpc.protobuf.services.ProtoReflectionServiceV1.FileDescriptorIndex
- filename_ - Variable in class io.grpc.channelz.v1.Address.UdsAddress.Builder
- filename_ - Variable in class io.grpc.channelz.v1.Address.UdsAddress
- FILENAME_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.Address.UdsAddress
- fill() - Method in class io.grpc.internal.GzipInflatingBuffer
- fillInStackTrace() - Method in exception class io.grpc.rls.LbPolicyConfiguration.InvalidChildPolicyConfigException
- filterAttributes(Attributes) - Method in class io.grpc.netty.ClientTransportLifecycleManager
- 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.
- filterTransport(Attributes) - Method in class io.grpc.internal.InternalSubchannel.TransportListener
- filterTransport(Attributes) - Method in class io.grpc.internal.ManagedChannelImpl.DelayedTransportListener
- filterTransport(Attributes) - Method in interface io.grpc.internal.ManagedClientTransport.Listener
-
Called just before
ManagedClientTransport.Listener.transportReady()
to allow direct modification of transport Attributes. - finalizeAndDump() - Method in class io.grpc.services.CallMetricRecorder
-
Returns all request cost metric values.
- finalizeAndDump(CallMetricRecorder) - Static method in class io.grpc.services.InternalCallMetricRecorder
- finalizeAndDump2() - Method in class io.grpc.services.CallMetricRecorder
-
Returns all save metric values.
- finalizeAndDump2(CallMetricRecorder) - Static method in class io.grpc.services.InternalCallMetricRecorder
- finalized - Variable in class io.grpc.internal.MetadataApplierImpl
- finalizeWith(ClientStream) - Method in class io.grpc.internal.MetadataApplierImpl
- findJdkProvider() - Static method in class io.grpc.netty.GrpcSslContexts
- findServer(SocketAddress) - Static method in class io.grpc.inprocess.InProcessServer
- fine(String, Object...) - Method in interface io.grpc.servlet.AsyncServletOutputStreamWriter.Log
- fine(String, Object...) - Method in interface io.grpc.servlet.jakarta.AsyncServletOutputStreamWriter.Log
- finest(String, Object...) - Method in interface io.grpc.servlet.AsyncServletOutputStreamWriter.Log
- finest(String, Object...) - Method in interface io.grpc.servlet.jakarta.AsyncServletOutputStreamWriter.Log
- fireProtocolNegotiationEvent(ChannelHandlerContext) - Method in class io.grpc.netty.ProtocolNegotiators.ProtocolNegotiationHandler
- fireProtocolNegotiationEvent(ChannelHandlerContext, SSLSession) - Method in class io.grpc.netty.ProtocolNegotiators.ServerTlsHandler
- firstHeaders - Variable in class io.grpc.CompositeCallCredentials.CombiningMetadataApplier
- firstPass - Variable in class io.grpc.internal.PickFirstLeafLoadBalancer
- firstResponseReceived - Variable in class io.grpc.stub.ClientCalls.StreamObserverToCallListenerAdapter
- firstSettings - Variable in class io.grpc.netty.NettyClientHandler.FrameListener
- firstSettings - Variable in class io.grpc.netty.NettyServerHandler.FrameListener
- fitToLimit() - Method in class io.grpc.rls.LinkedHashLruCache
-
Cleans up cache if needed to fit into max size bytes by removing expired entries and removing oldest entries by LRU order.
- fixedContextExecutor(Executor) - Method in class io.grpc.Context
-
Wrap an
Executor
so that it always executes with this context as theContext.current()
context. - FixedKeyManagerFactory - Class in io.grpc.netty
-
A KeyManagerFactory that returns a fixed list of key managers.
- FixedKeyManagerFactory(List<KeyManager>) - Constructor for class io.grpc.netty.FixedKeyManagerFactory
- FixedKeyManagerFactory.FixedKeyManagerFactorySpi - Class in io.grpc.netty
- FixedKeyManagerFactorySpi(List<KeyManager>) - Constructor for class io.grpc.netty.FixedKeyManagerFactory.FixedKeyManagerFactorySpi
- 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
- FixedPortProvider(int) - Constructor for class io.grpc.internal.ManagedChannelImplBuilder.FixedPortProvider
- FixedProtocolNegotiatorServerFactory(ProtocolNegotiator) - Constructor for class io.grpc.netty.ProtocolNegotiators.FixedProtocolNegotiatorServerFactory
- FixedResultPicker(LoadBalancer.PickResult) - Constructor for class io.grpc.LoadBalancer.FixedResultPicker
- fixedServerFactory(ProtocolNegotiator) - Static method in class io.grpc.netty.ProtocolNegotiators
- FixedTrustManagerFactory - Class in io.grpc.netty
-
A TrustManagerFactory that returns a fixed list of trust managers.
- FixedTrustManagerFactory(List<TrustManager>) - Constructor for class io.grpc.netty.FixedTrustManagerFactory
- FixedTrustManagerFactory.FixedTrustManagerFactorySpi - Class in io.grpc.netty
- FixedTrustManagerFactorySpi(List<TrustManager>) - Constructor for class io.grpc.netty.FixedTrustManagerFactory.FixedTrustManagerFactorySpi
- FLOW_CONTROL_ERROR - Enum constant in enum io.grpc.internal.GrpcUtil.Http2Error
- Flow-control in Streaming RPC - Search tag in class io.grpc.ClientCall
- Section
- flowControlPing - Variable in class io.grpc.netty.AbstractNettyHandler
- flowControlPing() - Method in class io.grpc.netty.AbstractNettyHandler
- FlowControlPinger(AbstractNettyHandler.PingLimiter) - Constructor for class io.grpc.netty.AbstractNettyHandler.FlowControlPinger
- FlowControlReader(Http2Connection) - Constructor for class io.grpc.netty.Utils.FlowControlReader
- flowControlWindow - Variable in class io.grpc.netty.NettyChannelBuilder
- flowControlWindow - Variable in class io.grpc.netty.NettyChannelBuilder.NettyTransportFactory
- flowControlWindow - Variable in class io.grpc.netty.NettyClientTransport
- flowControlWindow - Variable in class io.grpc.netty.NettyServer
- flowControlWindow - Variable in class io.grpc.netty.NettyServerBuilder
- flowControlWindow - Variable in class io.grpc.netty.NettyServerTransport
- 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 flow control window in bytes.
- flowControlWindowReader - Variable in class io.grpc.internal.TransportTracer
- FlowControlWindows(long, long) - Constructor for class io.grpc.internal.TransportTracer.FlowControlWindows
- flush() - Method in class io.grpc.inprocess.InProcessTransport.InProcessStream.InProcessClientStream
- flush() - Method in class io.grpc.inprocess.InProcessTransport.InProcessStream.InProcessServerStream
- flush() - Method in class io.grpc.internal.AbstractClientStream.GetFramer
- flush() - Method in class io.grpc.internal.AbstractStream
- flush() - Method in class io.grpc.internal.DelayedStream
- flush() - Method in class io.grpc.internal.ForwardingClientStream
- 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 class io.grpc.internal.RetriableStream
- flush() - Method in interface io.grpc.internal.Stream
-
Flushes any internally buffered messages to the remote end-point.
- flush() - Method in class io.grpc.netty.WriteQueue
-
Process the queue of commands and dispatch them to the stream.
- flush() - Method in class io.grpc.servlet.AsyncServletOutputStreamWriter
-
Called from application thread.
- flush() - Method in class io.grpc.servlet.jakarta.AsyncServletOutputStreamWriter
-
Called from application thread.
- flush(ChannelHandlerContext) - Method in class io.grpc.netty.WriteBufferingAndExceptionHandler
-
Calls to this method will not trigger an immediate flush.
- flushAction - Variable in class io.grpc.servlet.AsyncServletOutputStreamWriter
- flushAction - Variable in class io.grpc.servlet.jakarta.AsyncServletOutputStreamWriter
- flushRequested - Variable in class io.grpc.netty.WriteBufferingAndExceptionHandler
- forAddress(String, int) - Static method in class io.grpc.ForwardingChannelBuilder2
-
This method serves to force subclasses 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.ManagedChannelImplBuilder
- forAddress(String, int) - Static method in class io.grpc.ManagedChannelBuilder
-
Creates a channel with the target's address and port number.
- forAddress(String, int) - Static method in class io.grpc.netty.NettyChannelBuilder
-
Creates a new builder with the given host and port.
- forAddress(String, int, ChannelCredentials) - 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.inprocess.InProcessChannelBuilder
-
Create a channel builder that will connect to the server referenced by the given address.
- forAddress(SocketAddress) - Static method in class io.grpc.inprocess.InProcessServerBuilder
-
Create a server builder which listens on the given address.
- forAddress(SocketAddress) - Static method in class io.grpc.netty.NettyChannelBuilder
-
Creates a new builder with the given server address.
- forAddress(SocketAddress) - Static method in class io.grpc.netty.NettyServerBuilder
-
Creates a server builder configured with the given
SocketAddress
. - forAddress(SocketAddress, ChannelCredentials) - Static method in class io.grpc.netty.NettyChannelBuilder
-
Creates a new builder with the given server address.
- forAddress(SocketAddress, ServerCredentials) - Static method in class io.grpc.netty.NettyServerBuilder
-
Creates a server builder configured with the given
SocketAddress
. - forcefulClose(ChannelHandlerContext, ForcefulCloseCommand, ChannelPromise) - Method in class io.grpc.netty.NettyClientHandler
- forcefulClose(ChannelHandlerContext, ForcefulCloseCommand, ChannelPromise) - Method in class io.grpc.netty.NettyServerHandler
- ForcefulCloseCommand - Class in io.grpc.netty
-
A command to trigger close and close all streams.
- ForcefulCloseCommand(Status) - Constructor for class io.grpc.netty.ForcefulCloseCommand
- forceHeapBuffer - Variable in class io.grpc.netty.NettyServer
- forceHeapBuffer - Variable in class io.grpc.netty.NettyServerBuilder
- forClient() - Static method in class io.grpc.netty.GrpcSslContexts
-
Creates an SslContextBuilder with ciphers and APN appropriate for gRPC.
- forCode(long) - Static method in enum io.grpc.internal.GrpcUtil.Http2Error
-
Looks up the HTTP/2 error code enum value for the specified code.
- forConfig(OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig, ChannelLogger) - Static method in interface io.grpc.util.OutlierDetectionLoadBalancer.OutlierEjectionAlgorithm
-
Builds a list of algorithms that are enabled in the given config.
- forError(Status) - Static method in class io.grpc.InternalConfigSelector.Result
-
Creates a
Result
with the given error status. - fork() - Method in class io.grpc.Context
-
Create a new context which propagates the values of this context but does not cascade its cancellation.
- formatDeadlineExceededStatus() - Method in class io.grpc.internal.ClientCallImpl.CancellationHandler
- formatThrowableMessage(Status) - Static method in class io.grpc.Status
- 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
. - forNumber(int) - Static method in enum io.grpc.binarylog.v1.Address.Type
- forNumber(int) - Static method in enum io.grpc.binarylog.v1.GrpcLogEntry.EventType
- forNumber(int) - Static method in enum io.grpc.binarylog.v1.GrpcLogEntry.Logger
- forNumber(int) - Static method in enum io.grpc.binarylog.v1.GrpcLogEntry.PayloadCase
- forNumber(int) - Static method in enum io.grpc.channelz.v1.Address.AddressCase
- forNumber(int) - Static method in enum io.grpc.channelz.v1.ChannelConnectivityState.State
- forNumber(int) - Static method in enum io.grpc.channelz.v1.ChannelTraceEvent.ChildRefCase
- forNumber(int) - Static method in enum io.grpc.channelz.v1.ChannelTraceEvent.Severity
- forNumber(int) - Static method in enum io.grpc.channelz.v1.Security.ModelCase
- forNumber(int) - Static method in enum io.grpc.channelz.v1.Security.Tls.CipherSuiteCase
- forNumber(int) - Static method in enum io.grpc.health.v1.HealthCheckResponse.ServingStatus
- forNumber(int) - Static method in enum io.grpc.lb.v1.LoadBalanceRequest.LoadBalanceRequestTypeCase
- forNumber(int) - Static method in enum io.grpc.lb.v1.LoadBalanceResponse.LoadBalanceResponseTypeCase
- forNumber(int) - Static method in enum io.grpc.lookup.v1.RouteLookupRequest.Reason
- forNumber(int) - Static method in enum io.grpc.reflection.v1.ServerReflectionRequest.MessageRequestCase
- forNumber(int) - Static method in enum io.grpc.reflection.v1.ServerReflectionResponse.MessageResponseCase
- forNumber(int) - Static method in enum io.grpc.reflection.v1alpha.ServerReflectionRequest.MessageRequestCase
- forNumber(int) - Static method in enum io.grpc.reflection.v1alpha.ServerReflectionResponse.MessageResponseCase
- forPort(int) - Static method in class io.grpc.ForwardingServerBuilder
-
This method serves to force sub classes to "hide" this static factory.
- forPort(int) - Static method in class io.grpc.inprocess.InProcessServerBuilder
-
Always fails.
- forPort(int) - Static method in class io.grpc.internal.ServerImplBuilder
- forPort(int) - Static method in class io.grpc.netty.NettyServerBuilder
-
Creates a server builder that will bind to the given port.
- forPort(int) - Static method in class io.grpc.ServerBuilder
-
Static factory for creating a new ServerBuilder.
- forPort(int, ServerCredentials) - Static method in class io.grpc.netty.NettyServerBuilder
-
Creates a server builder that will bind to the given port.
- forResource(SharedResourceHolder.Resource<T>) - Static method in class io.grpc.internal.SharedResourcePool
- forServer(File, File) - Static method in class io.grpc.netty.GrpcSslContexts
-
Creates an SslContextBuilder with ciphers and APN appropriate for gRPC.
- forServer(File, File, String) - Static method in class io.grpc.netty.GrpcSslContexts
-
Creates an SslContextBuilder with ciphers and APN appropriate for gRPC.
- forServer(InputStream, InputStream) - Static method in class io.grpc.netty.GrpcSslContexts
-
Creates an SslContextBuilder with ciphers and APN appropriate for gRPC.
- forServer(InputStream, InputStream, String) - Static method in class io.grpc.netty.GrpcSslContexts
-
Creates an SslContextBuilder with ciphers and APN appropriate for gRPC.
- forTarget(String) - Static method in class io.grpc.ForwardingChannelBuilder2
-
This method serves to force subclasses to "hide" this static factory.
- forTarget(String) - Static method in class io.grpc.inprocess.InProcessChannelBuilder
-
Create a channel builder that will connect to the server referenced by the given target URI.
- forTarget(String) - Static method in class io.grpc.internal.ManagedChannelImplBuilder
- 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. - forTarget(String) - Static method in class io.grpc.netty.NettyChannelBuilder
-
Creates a new builder with the given target string that will be resolved by
NameResolver
. - forTarget(String) - Method in class io.grpc.rls.ChildLoadBalancerHelper.ChildLoadBalancerHelperProvider
- forTarget(String, ChannelCredentials) - Static method in class io.grpc.netty.NettyChannelBuilder
-
Creates a new builder with the given target string that will be resolved by
NameResolver
. - forTransientFailure(Status) - Static method in class io.grpc.ConnectivityStateInfo
-
Returns an instance for
TRANSIENT_FAILURE
, associated with an error status. - ForwardingChannelBuilder<T> - Class in io.grpc
-
A
ManagedChannelBuilder
that delegates all its builder methods to another builder by default. - ForwardingChannelBuilder() - Constructor for class io.grpc.ForwardingChannelBuilder
-
The default constructor.
- ForwardingChannelBuilder2<T> - Class in io.grpc
-
A
ManagedChannelBuilder
that delegates all its builder methods to another builder by default. - ForwardingChannelBuilder2() - Constructor for class io.grpc.ForwardingChannelBuilder2
-
The default constructor.
- ForwardingClientCall<ReqT,
RespT> - Class in io.grpc -
A
ClientCall
which forwards all of its methods to anotherClientCall
. - ForwardingClientCall() - Constructor for class io.grpc.ForwardingClientCall
- ForwardingClientCall.SimpleForwardingClientCall<ReqT,
RespT> - Class in io.grpc -
A simplified version of
ForwardingClientCall
where subclasses can pass in aClientCall
as the delegate. - ForwardingClientCallListener<RespT> - Class in io.grpc
-
A
ClientCall.Listener
which forwards all of its methods to anotherClientCall.Listener
. - ForwardingClientCallListener() - Constructor for class io.grpc.ForwardingClientCallListener
- ForwardingClientCallListener.SimpleForwardingClientCallListener<RespT> - Class in io.grpc
-
A simplified version of
ForwardingClientCallListener
where subclasses can pass in aClientCall.Listener
as the delegate. - ForwardingClientStream - Class in io.grpc.internal
- ForwardingClientStream() - Constructor for class io.grpc.internal.ForwardingClientStream
- ForwardingClientStreamListener - Class in io.grpc.internal
- ForwardingClientStreamListener() - Constructor for class io.grpc.internal.ForwardingClientStreamListener
- ForwardingClientStreamTracer - Class in io.grpc.internal
- ForwardingClientStreamTracer - Class in io.grpc.util
- ForwardingClientStreamTracer() - Constructor for class io.grpc.internal.ForwardingClientStreamTracer
- ForwardingClientStreamTracer() - Constructor for class io.grpc.util.ForwardingClientStreamTracer
- ForwardingConnectionClientTransport - Class in io.grpc.internal
- ForwardingConnectionClientTransport() - Constructor for class io.grpc.internal.ForwardingConnectionClientTransport
- ForwardingDeframerListener - Class in io.grpc.internal
-
Forwards listener callbacks to a delegate.
- ForwardingDeframerListener() - Constructor for class io.grpc.internal.ForwardingDeframerListener
- ForwardingLoadBalancer - Class in io.grpc.util
- ForwardingLoadBalancer() - Constructor for class io.grpc.util.ForwardingLoadBalancer
- ForwardingLoadBalancerHelper - Class in io.grpc.util
- ForwardingLoadBalancerHelper() - Constructor for class io.grpc.util.ForwardingLoadBalancerHelper
- ForwardingManagedChannel - Class in io.grpc.internal
- ForwardingManagedChannel(ManagedChannel) - Constructor for class io.grpc.internal.ForwardingManagedChannel
- ForwardingNameResolver - Class in io.grpc.internal
-
A forwarding class to ensure non overridden methods are forwarded to the delegate.
- ForwardingNameResolver(NameResolver) - Constructor for class io.grpc.internal.ForwardingNameResolver
- ForwardingReadableBuffer - Class in io.grpc.internal
-
Base class for a wrapper around another
ReadableBuffer
. - ForwardingReadableBuffer(ReadableBuffer) - Constructor for class io.grpc.internal.ForwardingReadableBuffer
-
Constructor.
- ForwardingServerBuilder<T> - Class in io.grpc
-
A
ServerBuilder
that delegates all its builder methods to another builder by default. - ForwardingServerBuilder() - Constructor for class io.grpc.ForwardingServerBuilder
-
The default constructor.
- ForwardingServerCall<ReqT,
RespT> - Class in io.grpc -
A
ServerCall
which forwards all of its methods to anotherServerCall
. - ForwardingServerCall() - Constructor for class io.grpc.ForwardingServerCall
- ForwardingServerCall.SimpleForwardingServerCall<ReqT,
RespT> - Class in io.grpc -
A simplified version of
ForwardingServerCall
where subclasses can pass in aServerCall
as the delegate. - ForwardingServerCallListener<ReqT> - Class in io.grpc
-
A
ServerCall.Listener
which forwards all of its methods to anotherServerCall.Listener
of matching parameterized types. - ForwardingServerCallListener() - Constructor for class io.grpc.ForwardingServerCallListener
- ForwardingServerCallListener.SimpleForwardingServerCallListener<ReqT> - Class in io.grpc
-
A simplified version of
ForwardingServerCallListener
where subclasses can pass in aServerCall.Listener
as the delegate. - ForwardingSubchannel - Class in io.grpc.util
- ForwardingSubchannel() - Constructor for class io.grpc.util.ForwardingSubchannel
- FRAME_SIZE_ERROR - Enum constant in enum io.grpc.internal.GrpcUtil.Http2Error
- FrameListener() - Constructor for class io.grpc.netty.NettyClientHandler.FrameListener
- FrameListener() - Constructor for class io.grpc.netty.NettyServerHandler.FrameListener
- framer - Variable in class io.grpc.internal.AbstractClientStream
- framer - Variable in class io.grpc.internal.AbstractServerStream
- 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.
- freeze() - Method in class io.grpc.stub.ClientCalls.CallToStreamObserverAdapter
- freeze() - Method in class io.grpc.stub.ServerCalls.ServerCallStreamObserverImpl
- freezeHedging() - Method in class io.grpc.internal.RetriableStream
- freezeHedging() - Method in class io.grpc.internal.RetriableStream.State
- freezeProtocolNegotiatorFactory - Variable in class io.grpc.netty.NettyChannelBuilder
- freezeProtocolNegotiatorFactory - Variable in class io.grpc.netty.NettyServerBuilder
- from(ChannelCredentials) - Static method in class io.grpc.netty.ProtocolNegotiators
- from(ServerCredentials) - Static method in class io.grpc.netty.ProtocolNegotiators
- FromChannelCredentialsResult(ProtocolNegotiator.ClientFactory, CallCredentials, String) - Constructor for class io.grpc.netty.ProtocolNegotiators.FromChannelCredentialsResult
- fromCode(Status.Code) - Static method in class io.grpc.Status
-
Return a
Status
given a canonical errorStatus.Code
object. - fromCodeValue(byte[]) - Static method in class io.grpc.Status
- fromCodeValue(int) - Static method in class io.grpc.Status
-
Return a
Status
given a canonical errorStatus.Code
value. - fromCodeValueSlow(byte[]) - Static method in class io.grpc.Status
- fromConfig(Object) - Static method in class io.grpc.NameResolver.ConfigOrError
-
Returns a
NameResolver.ConfigOrError
for the successfully parsed config. - fromError(Status) - Static method in class io.grpc.NameResolver.ConfigOrError
-
Returns a
NameResolver.ConfigOrError
for the failure to parse the config. - FromServerCredentialsResult(ProtocolNegotiator.ServerFactory, String) - Constructor for class io.grpc.netty.ProtocolNegotiators.FromServerCredentialsResult
- fromServiceConfig(Map<String, ?>, boolean, int, int, Object) - Static method in class io.grpc.internal.ManagedChannelServiceConfig
-
Parses the Channel level config values (e.g.
- fromStatus(Status) - Static method in class io.grpc.StatusOr
-
Construct from a non-Ok status.
- fromStatusAndTrailers(Status, Metadata) - Static method in class io.grpc.protobuf.StatusProto
-
Extracts the
google.rpc.Status
from trailers, and makes sure they match the gRPCstatus
. - fromThrowable(Throwable) - Static method in class io.grpc.protobuf.StatusProto
-
Extract a
Status
instance from the causal chain of aThrowable
. - fromThrowable(Throwable) - Static method in class io.grpc.Status
- fromValue(T) - Static method in class io.grpc.StatusOr
-
Construct from a value.
- frozen - Variable in class io.grpc.stub.ClientCalls.CallToStreamObserverAdapter
- frozen - Variable in class io.grpc.stub.ServerCalls.ServerCallStreamObserverImpl
- FULL_STREAM_DECOMPRESSION_ENCODINGS - Static variable in class io.grpc.internal.ClientCallImpl
- fullMethodName - Variable in class io.grpc.MethodDescriptor.Builder
- fullMethodName - Variable in class io.grpc.MethodDescriptor
- fullMethodName() - Element in annotation type io.grpc.stub.annotations.RpcMethod
-
The fully qualified method name.
- fullStreamDecompression - Variable in class io.grpc.internal.AbstractClientStream.TransportState
- fullStreamDecompression - Variable in class io.grpc.internal.ClientCallImpl
- fullStreamDecompression - Variable in class io.grpc.internal.ManagedChannelImpl
- fullStreamDecompression - Variable in class io.grpc.internal.ManagedChannelImplBuilder
- fullStreamDecompressor - Variable in class io.grpc.internal.MessageDeframer
- future - Variable in class io.grpc.internal.RetriableStream.FutureCanceller
- future - Variable in class io.grpc.SynchronizationContext.ScheduledHandle
- FUTURE - Enum constant in enum io.grpc.stub.ClientCalls.StubType
- FUTURE - Enum constant in enum io.grpc.stub.InternalClientCalls.StubType
- FutureCanceller(Object) - Constructor for class io.grpc.internal.RetriableStream.FutureCanceller
- FutureRunnable() - Constructor for class io.grpc.internal.Rescheduler.FutureRunnable
- futureUnaryCall(ClientCall<ReqT, RespT>, ReqT) - Static method in class io.grpc.stub.ClientCalls
-
Executes a unary call and returns a
ListenableFuture
to the response.
G
- gaugeRegistration - Variable in class io.grpc.rls.CachingRlsLbClient
- generateFullMethodName(String, String) - Static method in class io.grpc.MethodDescriptor
-
Generate the fully qualified method name.
- generateLoadReport() - Method in class io.grpc.grpclb.GrpclbClientLoadRecorder
-
Generate the report with the data recorded this LB stream since the last report.
- generateName() - Static method in class io.grpc.inprocess.InProcessServerBuilder
-
Generates a new server name that is unique each time.
- generateValidTChars() - Static method in class io.grpc.Metadata.Key
- generation - Variable in class io.grpc.Context
- geRawMethodName(MethodDescriptor<?, ?>) - Method in class io.grpc.InternalMethodDescriptor
- get - Variable in class io.grpc.netty.CreateStreamCommand
- get() - Method in class io.grpc.Context.Key
-
Get the value from the
Context.current()
context for this key. - 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() - Method in interface io.grpc.rls.RlsLoadBalancer.CachingRlsLbClientBuilderProvider
- get() - Method in class io.grpc.rls.RlsLoadBalancer.DefaultCachingRlsLbClientBuilderProvider
- get() - Method in class io.grpc.servlet.jakarta.ServletServerStream.TrailerSupplier
- get() - Method in class io.grpc.servlet.ServletServerStream.TrailerSupplier
- get(long) - Method in class io.grpc.rls.AdaptiveThrottler.TimeBasedAccumulator
-
Returns the count of the statistic using the specified time value as the current time.
- get(Attributes.Key<T>) - Method in class io.grpc.Attributes
-
Gets the value for the key, or
null
if it's not present. - 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.
- get(PersistentHashArrayMappedTrie.Node<K, V>, K) - Static method in class io.grpc.PersistentHashArrayMappedTrie
-
Returns the value with the specified key, or
null
if it does not exist. - get(RlsProtoData.RouteLookupRequest) - Method in class io.grpc.rls.CachingRlsLbClient
-
Returns async response of the
request
. - get(AsciiString) - Method in class io.grpc.netty.GrpcHttp2HeadersUtils.GrpcHttp2InboundHeaders
- get(CharSequence) - Method in class io.grpc.netty.AbstractHttp2Headers
- get(CharSequence) - Method in class io.grpc.netty.GrpcHttp2HeadersUtils.GrpcHttp2RequestHeaders
- get(CharSequence) - Method in class io.grpc.netty.GrpcHttp2HeadersUtils.GrpcHttp2ResponseHeaders
- get(CharSequence, CharSequence) - Method in class io.grpc.netty.AbstractHttp2Headers
- get(K, int, int) - Method in class io.grpc.PersistentHashArrayMappedTrie.CollisionLeaf
- get(K, int, int) - Method in class io.grpc.PersistentHashArrayMappedTrie.CompressedIndex
- get(K, int, int) - Method in class io.grpc.PersistentHashArrayMappedTrie.Leaf
- get(K, int, int) - Method in interface io.grpc.PersistentHashArrayMappedTrie.Node
- GET_CLIENT_INTERCEPTOR_METHOD - Static variable in class io.grpc.internal.ManagedChannelImplBuilder
- getAcceptedIssuers() - Method in class io.grpc.util.AdvancedTlsX509TrustManager
- getActive() - Method in class io.grpc.channelz.v1.SocketOptionLinger.Builder
-
active maps to `struct linger.l_onoff`
- getActive() - Method in class io.grpc.channelz.v1.SocketOptionLinger
-
active maps to `struct linger.l_onoff`
- getActive() - Method in interface io.grpc.channelz.v1.SocketOptionLingerOrBuilder
-
active maps to `struct linger.l_onoff`
- getAdditional() - Method in class io.grpc.channelz.v1.SocketOption.Builder
-
Additional data associated with the socket option.
- getAdditional() - Method in class io.grpc.channelz.v1.SocketOption
-
Additional data associated with the socket option.
- getAdditional() - Method in interface io.grpc.channelz.v1.SocketOptionOrBuilder
-
Additional data associated with the socket option.
- getAdditionalBuilder() - Method in class io.grpc.channelz.v1.SocketOption.Builder
-
Additional data associated with the socket option.
- getAdditionalFieldBuilder() - Method in class io.grpc.channelz.v1.SocketOption.Builder
-
Additional data associated with the socket option.
- getAdditionalOrBuilder() - Method in class io.grpc.channelz.v1.SocketOption.Builder
-
Additional data associated with the socket option.
- getAdditionalOrBuilder() - Method in class io.grpc.channelz.v1.SocketOption
-
Additional data associated with the socket option.
- getAdditionalOrBuilder() - Method in interface io.grpc.channelz.v1.SocketOptionOrBuilder
-
Additional data associated with the socket option.
- getAddress() - Method in class io.grpc.binarylog.v1.Address.Builder
-
string address = 2;
- getAddress() - Method in class io.grpc.binarylog.v1.Address
-
string address = 2;
- getAddress() - Method in interface io.grpc.binarylog.v1.AddressOrBuilder
-
string address = 2;
- getAddress(LoadBalancer.Subchannel) - Method in class io.grpc.internal.PickFirstLeafLoadBalancer
- getAddressBytes() - Method in class io.grpc.binarylog.v1.Address.Builder
-
string address = 2;
- getAddressBytes() - Method in class io.grpc.binarylog.v1.Address
-
string address = 2;
- getAddressBytes() - Method in interface io.grpc.binarylog.v1.AddressOrBuilder
-
string address = 2;
- getAddressCase() - Method in class io.grpc.channelz.v1.Address.Builder
- getAddressCase() - Method in class io.grpc.channelz.v1.Address
- getAddressCase() - Method in interface io.grpc.channelz.v1.AddressOrBuilder
- getAddresses() - Method in class io.grpc.EquivalentAddressGroup
-
Returns an immutable list of the addresses.
- getAddresses() - Method in class io.grpc.grpclb.BackendAddressGroup
- getAddresses() - Method in class io.grpc.LoadBalancer.CreateSubchannelArgs
-
Returns the addresses, which is an unmodifiable list.
- getAddresses() - Method in class io.grpc.LoadBalancer.ResolvedAddresses
-
Gets the server addresses.
- getAddresses() - Method in class io.grpc.LoadBalancer.Subchannel
-
Returns the addresses that this Subchannel is bound to.
- getAddresses() - Method in class io.grpc.NameResolver.ResolutionResult
-
Deprecated.Will be superseded by getAddressesOrError
- getAddressesOrError() - Method in class io.grpc.NameResolver.ResolutionResult
-
Gets the addresses resolved by name resolution or the error in doing so.
- getAddressGroups() - Method in class io.grpc.internal.InternalSubchannel
- getAdvertisedMessageEncodings() - Method in class io.grpc.DecompressorRegistry
-
Provides a list of all message encodings that have decompressors available and should be advertised.
- getAggregatedState() - Method in interface io.grpc.rls.SubchannelStateManager
-
Returns representative subchannel status from all registered subchannels.
- getAggregatedState() - Method in class io.grpc.rls.SubchannelStateManagerImpl
- 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.
- getAll(CharSequence) - Method in class io.grpc.netty.AbstractHttp2Headers
- getAll(CharSequence) - Method in class io.grpc.netty.GrpcHttp2HeadersUtils.GrpcHttp2InboundHeaders
- getAll(CharSequence) - Method in class io.grpc.netty.GrpcHttp2HeadersUtils.GrpcHttp2RequestHeaders
- getAllAddresses() - Method in class io.grpc.internal.ManagedChannelImpl.SubchannelImpl
- getAllAddresses() - Method in class io.grpc.LoadBalancer.Subchannel
-
Returns the addresses that this Subchannel is bound to.
- getAllAddresses() - Method in class io.grpc.util.ForwardingSubchannel
- getAllAndRemove(CharSequence) - Method in class io.grpc.netty.AbstractHttp2Headers
- getAllExtensionNumbersOfType() - Method in class io.grpc.reflection.v1.ServerReflectionRequest.Builder
-
Finds the tag numbers used by all known extensions of the given message type, and appends them to ExtensionNumberResponse in an undefined order.
- getAllExtensionNumbersOfType() - Method in class io.grpc.reflection.v1.ServerReflectionRequest
-
Finds the tag numbers used by all known extensions of the given message type, and appends them to ExtensionNumberResponse in an undefined order.
- getAllExtensionNumbersOfType() - Method in interface io.grpc.reflection.v1.ServerReflectionRequestOrBuilder
-
Finds the tag numbers used by all known extensions of the given message type, and appends them to ExtensionNumberResponse in an undefined order.
- getAllExtensionNumbersOfType() - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest.Builder
-
Finds the tag numbers used by all known extensions of extendee_type, and appends them to ExtensionNumberResponse in an undefined order.
- getAllExtensionNumbersOfType() - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest
-
Finds the tag numbers used by all known extensions of extendee_type, and appends them to ExtensionNumberResponse in an undefined order.
- getAllExtensionNumbersOfType() - Method in interface io.grpc.reflection.v1alpha.ServerReflectionRequestOrBuilder
-
Finds the tag numbers used by all known extensions of extendee_type, and appends them to ExtensionNumberResponse in an undefined order.
- getAllExtensionNumbersOfTypeBytes() - Method in class io.grpc.reflection.v1.ServerReflectionRequest.Builder
-
Finds the tag numbers used by all known extensions of the given message type, and appends them to ExtensionNumberResponse in an undefined order.
- getAllExtensionNumbersOfTypeBytes() - Method in class io.grpc.reflection.v1.ServerReflectionRequest
-
Finds the tag numbers used by all known extensions of the given message type, and appends them to ExtensionNumberResponse in an undefined order.
- getAllExtensionNumbersOfTypeBytes() - Method in interface io.grpc.reflection.v1.ServerReflectionRequestOrBuilder
-
Finds the tag numbers used by all known extensions of the given message type, and appends them to ExtensionNumberResponse in an undefined order.
- getAllExtensionNumbersOfTypeBytes() - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest.Builder
-
Finds the tag numbers used by all known extensions of extendee_type, and appends them to ExtensionNumberResponse in an undefined order.
- getAllExtensionNumbersOfTypeBytes() - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest
-
Finds the tag numbers used by all known extensions of extendee_type, and appends them to ExtensionNumberResponse in an undefined order.
- getAllExtensionNumbersOfTypeBytes() - Method in interface io.grpc.reflection.v1alpha.ServerReflectionRequestOrBuilder
-
Finds the tag numbers used by all known extensions of extendee_type, and appends them to ExtensionNumberResponse in an undefined order.
- getAllExtensionNumbersResponse() - Method in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
-
This message is used to answer all_extension_numbers_of_type requests.
- getAllExtensionNumbersResponse() - Method in class io.grpc.reflection.v1.ServerReflectionResponse
-
This message is used to answer all_extension_numbers_of_type requests.
- getAllExtensionNumbersResponse() - Method in interface io.grpc.reflection.v1.ServerReflectionResponseOrBuilder
-
This message is used to answer all_extension_numbers_of_type requests.
- getAllExtensionNumbersResponse() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
-
This message is used to answer all_extension_numbers_of_type requst.
- getAllExtensionNumbersResponse() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse
-
This message is used to answer all_extension_numbers_of_type requst.
- getAllExtensionNumbersResponse() - Method in interface io.grpc.reflection.v1alpha.ServerReflectionResponseOrBuilder
-
This message is used to answer all_extension_numbers_of_type requst.
- getAllExtensionNumbersResponseBuilder() - Method in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
-
This message is used to answer all_extension_numbers_of_type requests.
- getAllExtensionNumbersResponseBuilder() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
-
This message is used to answer all_extension_numbers_of_type requst.
- getAllExtensionNumbersResponseFieldBuilder() - Method in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
-
This message is used to answer all_extension_numbers_of_type requests.
- getAllExtensionNumbersResponseFieldBuilder() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
-
This message is used to answer all_extension_numbers_of_type requst.
- getAllExtensionNumbersResponseOrBuilder() - Method in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
-
This message is used to answer all_extension_numbers_of_type requests.
- getAllExtensionNumbersResponseOrBuilder() - Method in class io.grpc.reflection.v1.ServerReflectionResponse
-
This message is used to answer all_extension_numbers_of_type requests.
- getAllExtensionNumbersResponseOrBuilder() - Method in interface io.grpc.reflection.v1.ServerReflectionResponseOrBuilder
-
This message is used to answer all_extension_numbers_of_type requests.
- getAllExtensionNumbersResponseOrBuilder() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
-
This message is used to answer all_extension_numbers_of_type requst.
- getAllExtensionNumbersResponseOrBuilder() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse
-
This message is used to answer all_extension_numbers_of_type requst.
- getAllExtensionNumbersResponseOrBuilder() - Method in interface io.grpc.reflection.v1alpha.ServerReflectionResponseOrBuilder
-
This message is used to answer all_extension_numbers_of_type requst.
- getAllExtensions(ServerReflectionRequest) - Method in class io.grpc.protobuf.services.ProtoReflectionServiceV1.ProtoReflectionStreamObserver
- getAllRecords(String, String) - Method in class io.grpc.internal.JndiResourceResolverFactory.JndiRecordFetcher
- getAllRecords(String, String) - Method in interface io.grpc.internal.JndiResourceResolverFactory.RecordFetcher
- getAndRemove(CharSequence) - Method in class io.grpc.netty.AbstractHttp2Headers
- getAndRemove(CharSequence, CharSequence) - Method in class io.grpc.netty.AbstractHttp2Headers
- getAndResetBytesConsumed() - Method in class io.grpc.internal.GzipInflatingBuffer
-
Reports bytes consumed by calls to
GzipInflatingBuffer.inflateBytes(byte[], int, int)
since the last invocation of this method, then resets the count to zero. - getAndResetDeflatedBytesConsumed() - Method in class io.grpc.internal.GzipInflatingBuffer
-
Reports bytes consumed by the inflater since the last invocation of this method, then resets the count to zero.
- getApplicationUtilization() - Method in class io.grpc.services.MetricReport
- getAppListener() - Method in class io.grpc.internal.ApplicationThreadDeframer
- getAtomicHelper() - Static method in class io.grpc.internal.SerializingExecutor
- 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.inprocess.InProcessTransport
- getAttributes() - Method in class io.grpc.inprocess.InProcessTransport.InProcessStream.InProcessClientStream
- getAttributes() - Method in class io.grpc.inprocess.InProcessTransport.InProcessStream.InProcessServerStream
- getAttributes() - Method in class io.grpc.internal.AbstractServerStream
- getAttributes() - Method in class io.grpc.internal.ClientCallImpl
- 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.DelayedClientCall
- getAttributes() - Method in class io.grpc.internal.DelayedStream
- getAttributes() - Method in class io.grpc.internal.ForwardingClientStream
- getAttributes() - Method in class io.grpc.internal.ForwardingConnectionClientTransport
- getAttributes() - Method in class io.grpc.internal.ManagedChannelImpl.SubchannelImpl
- getAttributes() - Method in class io.grpc.internal.NoopClientStream
- getAttributes() - Method in class io.grpc.internal.RetriableStream
- getAttributes() - Method in class io.grpc.internal.ServerCallImpl
- getAttributes() - Method in class io.grpc.internal.ServerCallInfoImpl
- getAttributes() - Method in interface io.grpc.internal.ServerStream
-
Attributes describing stream.
- getAttributes() - Method in class io.grpc.LoadBalancer.CreateSubchannelArgs
-
Returns the attributes.
- getAttributes() - Method in class io.grpc.LoadBalancer.ResolvedAddresses
-
Gets the attributes associated with these addresses.
- getAttributes() - Method in class io.grpc.LoadBalancer.Subchannel
-
The same attributes passed to
Helper.createSubchannel()
. - getAttributes() - Method in class io.grpc.NameResolver.ResolutionResult
-
Gets the attributes associated with the addresses resolved by name resolution.
- getAttributes() - Method in class io.grpc.netty.NettyClientHandler
-
The protocol negotiation attributes, available once the protocol negotiation completes; otherwise returns
Attributes.EMPTY
. - getAttributes() - Method in class io.grpc.netty.NettyClientStream
- getAttributes() - Method in class io.grpc.netty.NettyClientTransport
- getAttributes() - Method in class io.grpc.netty.NettyServerStream
- getAttributes() - Method in class io.grpc.netty.ProtocolNegotiationEvent
- getAttributes() - Method in class io.grpc.PartialForwardingClientCall
- getAttributes() - Method in class io.grpc.PartialForwardingServerCall
- getAttributes() - Method in class io.grpc.ServerCall
-
Returns properties of a single call.
- getAttributes() - Method in class io.grpc.ServerStreamTracer.ReadOnlyServerCall
-
Deprecated.
- getAttributes() - Method in class io.grpc.ServerStreamTracer.ServerCallInfo
- getAttributes() - Method in class io.grpc.servlet.jakarta.ServletServerStream
- getAttributes() - Method in class io.grpc.servlet.ServletServerStream
- getAttributes() - Method in class io.grpc.util.ForwardingSubchannel
- getAttributes() - Method in class io.grpc.util.HealthProducerHelper.HealthProducerSubchannel
- getAttributes() - Method in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionSubchannel
- getAttributes() - Method in class io.grpc.util.TransmitStatusRuntimeExceptionInterceptor.SerializingServerCall
- getAttributes(ProtocolNegotiationEvent) - Static method in class io.grpc.netty.InternalProtocolNegotiationEvent
- getAuthority() - Method in class io.grpc.binarylog.v1.ClientHeader.Builder
-
A single process may be used to run multiple virtual servers with different identities.
- getAuthority() - Method in class io.grpc.binarylog.v1.ClientHeader
-
A single process may be used to run multiple virtual servers with different identities.
- getAuthority() - Method in interface io.grpc.binarylog.v1.ClientHeaderOrBuilder
-
A single process may be used to run multiple virtual servers with different identities.
- 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.inprocess.InProcessTransport.InProcessStream.InProcessServerStream
- getAuthority() - Method in class io.grpc.internal.AbstractServerStream
- getAuthority() - Method in class io.grpc.internal.ClientTransportFactory.ClientTransportOptions
- getAuthority() - Method in class io.grpc.internal.InternalSubchannel
-
Returns the authority string associated with this Subchannel.
- getAuthority() - Method in class io.grpc.internal.ManagedChannelImpl.LbHelperImpl
- getAuthority() - Method in class io.grpc.internal.ServerCallImpl
- getAuthority() - Method in class io.grpc.internal.ServerCallInfoImpl
- 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.netty.GrpcHttp2ConnectionHandler
-
Returns the authority of the server.
- getAuthority() - Method in class io.grpc.netty.NettyClientHandler
- getAuthority() - Method in class io.grpc.netty.NettyServerStream
- getAuthority() - Method in class io.grpc.PartialForwardingServerCall
- getAuthority() - Method in class io.grpc.ServerCall
-
Gets the authority this call is addressed to.
- getAuthority() - Method in class io.grpc.ServerStreamTracer.ReadOnlyServerCall
-
Deprecated.
- getAuthority() - Method in class io.grpc.ServerStreamTracer.ServerCallInfo
- getAuthority() - Method in class io.grpc.servlet.jakarta.ServletServerStream
- getAuthority() - Method in class io.grpc.servlet.ServletServerStream
- getAuthority() - Method in class io.grpc.util.ForwardingLoadBalancerHelper
- getAuthority() - Method in class io.grpc.util.TransmitStatusRuntimeExceptionInterceptor.SerializingServerCall
- getAuthority(HttpServletRequest) - Static method in class io.grpc.servlet.jakarta.ServletAdapter
- getAuthority(HttpServletRequest) - Static method in class io.grpc.servlet.ServletAdapter
- getAuthorityBytes() - Method in class io.grpc.binarylog.v1.ClientHeader.Builder
-
A single process may be used to run multiple virtual servers with different identities.
- getAuthorityBytes() - Method in class io.grpc.binarylog.v1.ClientHeader
-
A single process may be used to run multiple virtual servers with different identities.
- getAuthorityBytes() - Method in interface io.grpc.binarylog.v1.ClientHeaderOrBuilder
-
A single process may be used to run multiple virtual servers with different identities.
- getAuthorityFromAddress(SocketAddress) - Static method in class io.grpc.netty.NettyChannelBuilder
- getBackoffMultiplierFromRetryPolicy(Map<String, ?>) - Static method in class io.grpc.internal.ServiceConfigUtil
- getBalanceLoadMethod - Static variable in class io.grpc.lb.v1.LoadBalancerGrpc
- getBalanceLoadMethod() - Static method in class io.grpc.lb.v1.LoadBalancerGrpc
- getBareMethodName() - Method in class io.grpc.MethodDescriptor
-
A convenience method for
extractBareMethodName(getFullMethodName())
. - getBaseTypeName() - Method in class io.grpc.reflection.v1.ExtensionNumberResponse.Builder
-
Full name of the base type, including the package name.
- getBaseTypeName() - Method in class io.grpc.reflection.v1.ExtensionNumberResponse
-
Full name of the base type, including the package name.
- getBaseTypeName() - Method in interface io.grpc.reflection.v1.ExtensionNumberResponseOrBuilder
-
Full name of the base type, including the package name.
- getBaseTypeName() - Method in class io.grpc.reflection.v1alpha.ExtensionNumberResponse.Builder
-
Full name of the base type, including the package name.
- getBaseTypeName() - Method in class io.grpc.reflection.v1alpha.ExtensionNumberResponse
-
Full name of the base type, including the package name.
- getBaseTypeName() - Method in interface io.grpc.reflection.v1alpha.ExtensionNumberResponseOrBuilder
-
Full name of the base type, including the package name.
- getBaseTypeNameBytes() - Method in class io.grpc.reflection.v1.ExtensionNumberResponse.Builder
-
Full name of the base type, including the package name.
- getBaseTypeNameBytes() - Method in class io.grpc.reflection.v1.ExtensionNumberResponse
-
Full name of the base type, including the package name.
- getBaseTypeNameBytes() - Method in interface io.grpc.reflection.v1.ExtensionNumberResponseOrBuilder
-
Full name of the base type, including the package name.
- getBaseTypeNameBytes() - Method in class io.grpc.reflection.v1alpha.ExtensionNumberResponse.Builder
-
Full name of the base type, including the package name.
- getBaseTypeNameBytes() - Method in class io.grpc.reflection.v1alpha.ExtensionNumberResponse
-
Full name of the base type, including the package name.
- getBaseTypeNameBytes() - Method in interface io.grpc.reflection.v1alpha.ExtensionNumberResponseOrBuilder
-
Full name of the base type, including the package name.
- getBinaryStreamMarshaller(Metadata.Key<T>) - Static method in class io.grpc.Metadata.LazyValue
- getBoolean(CharSequence) - Method in class io.grpc.netty.AbstractHttp2Headers
- getBoolean(CharSequence, boolean) - Method in class io.grpc.netty.AbstractHttp2Headers
- getBoolean(Map<String, ?>, String) - Static method in class io.grpc.internal.JsonUtil
-
Gets a boolean from an object for the given key.
- getBooleanAndRemove(CharSequence) - Method in class io.grpc.netty.AbstractHttp2Headers
- getBooleanAndRemove(CharSequence, boolean) - Method in class io.grpc.netty.AbstractHttp2Headers
- getBucketBoundaries() - Method in class io.grpc.DoubleHistogramMetricInstrument
- getBucketBoundaries() - Method in class io.grpc.LongHistogramMetricInstrument
- getBundleMap() - Method in class io.grpc.internal.SpiffeUtil.SpiffeBundle
- getByte(CharSequence) - Method in class io.grpc.netty.AbstractHttp2Headers
- getByte(CharSequence, byte) - Method in class io.grpc.netty.AbstractHttp2Headers
- getByteAndRemove(CharSequence) - Method in class io.grpc.netty.AbstractHttp2Headers
- getByteAndRemove(CharSequence, byte) - Method in class io.grpc.netty.AbstractHttp2Headers
- getByteBufAllocator(boolean) - Static method in class io.grpc.netty.Utils
- getByteBuffer() - Method in interface io.grpc.HasByteBuffer
-
Gets a
ByteBuffer
containing some bytes of the content next to be read, ornull
if has reached end of the content. - getByteBuffer() - Method in class io.grpc.internal.AbstractReadableBuffer
- getByteBuffer() - Method in class io.grpc.internal.CompositeReadableBuffer
- getByteBuffer() - Method in class io.grpc.internal.ForwardingReadableBuffer
- getByteBuffer() - Method in interface io.grpc.internal.ReadableBuffer
-
Gets a
ByteBuffer
that contains some bytes of the content next to be read, ornull
if this buffer has been exhausted. - getByteBuffer() - Method in class io.grpc.internal.ReadableBuffers.BufferInputStream
- getByteBuffer() - Method in class io.grpc.internal.ReadableBuffers.ByteReadableBufferWrapper
- getByteBuffer() - Method in class io.grpc.netty.NettyReadableBuffer
- getCacheSizeBytes() - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
Rough indicator of amount of memory to use for the client cache.
- getCacheSizeBytes() - Method in class io.grpc.lookup.v1.RouteLookupConfig
-
Rough indicator of amount of memory to use for the client cache.
- getCacheSizeBytes() - Method in interface io.grpc.lookup.v1.RouteLookupConfigOrBuilder
-
Rough indicator of amount of memory to use for the client cache.
- getCallCredentials() - Method in class io.grpc.CompositeChannelCredentials
- getCallExecutor(CallOptions) - Method in class io.grpc.internal.ManagedChannelImpl
- getCallId() - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
Uniquely identifies a call.
- getCallId() - Method in class io.grpc.binarylog.v1.GrpcLogEntry
-
Uniquely identifies a call.
- getCallId() - Method in interface io.grpc.binarylog.v1.GrpcLogEntryOrBuilder
-
Uniquely identifies a call.
- getCallOptions() - Method in class io.grpc.CallCredentials.RequestInfo
-
The call options used to call this RPC.
- getCallOptions() - Method in class io.grpc.ClientStreamTracer.StreamInfo
-
Returns the effective CallOptions of the call.
- getCallOptions() - Method in class io.grpc.internal.PickSubchannelArgsImpl
- getCallOptions() - Method in class io.grpc.LoadBalancer.PickSubchannelArgs
-
Call options.
- getCallOptions() - Method in class io.grpc.stub.AbstractStub
-
The
CallOptions
of the stub. - getCallsFailed() - Method in class io.grpc.channelz.v1.ChannelData.Builder
-
The number of calls that have completed with a non-OK status
- getCallsFailed() - Method in class io.grpc.channelz.v1.ChannelData
-
The number of calls that have completed with a non-OK status
- getCallsFailed() - Method in interface io.grpc.channelz.v1.ChannelDataOrBuilder
-
The number of calls that have completed with a non-OK status
- getCallsFailed() - Method in class io.grpc.channelz.v1.ServerData.Builder
-
The number of incoming calls that have a completed with a non-OK status
- getCallsFailed() - Method in class io.grpc.channelz.v1.ServerData
-
The number of incoming calls that have a completed with a non-OK status
- getCallsFailed() - Method in interface io.grpc.channelz.v1.ServerDataOrBuilder
-
The number of incoming calls that have a completed with a non-OK status
- getCallsFinishedWithDrop(int) - Method in class io.grpc.lb.v1.ClientStats.Builder
-
The list of dropped calls.
- getCallsFinishedWithDrop(int) - Method in class io.grpc.lb.v1.ClientStats
-
The list of dropped calls.
- getCallsFinishedWithDrop(int) - Method in interface io.grpc.lb.v1.ClientStatsOrBuilder
-
The list of dropped calls.
- getCallsFinishedWithDropBuilder(int) - Method in class io.grpc.lb.v1.ClientStats.Builder
-
The list of dropped calls.
- getCallsFinishedWithDropBuilderList() - Method in class io.grpc.lb.v1.ClientStats.Builder
-
The list of dropped calls.
- getCallsFinishedWithDropCount() - Method in class io.grpc.lb.v1.ClientStats.Builder
-
The list of dropped calls.
- getCallsFinishedWithDropCount() - Method in class io.grpc.lb.v1.ClientStats
-
The list of dropped calls.
- getCallsFinishedWithDropCount() - Method in interface io.grpc.lb.v1.ClientStatsOrBuilder
-
The list of dropped calls.
- getCallsFinishedWithDropFieldBuilder() - Method in class io.grpc.lb.v1.ClientStats.Builder
- getCallsFinishedWithDropList() - Method in class io.grpc.lb.v1.ClientStats.Builder
-
The list of dropped calls.
- getCallsFinishedWithDropList() - Method in class io.grpc.lb.v1.ClientStats
-
The list of dropped calls.
- getCallsFinishedWithDropList() - Method in interface io.grpc.lb.v1.ClientStatsOrBuilder
-
The list of dropped calls.
- getCallsFinishedWithDropOrBuilder(int) - Method in class io.grpc.lb.v1.ClientStats.Builder
-
The list of dropped calls.
- getCallsFinishedWithDropOrBuilder(int) - Method in class io.grpc.lb.v1.ClientStats
-
The list of dropped calls.
- getCallsFinishedWithDropOrBuilder(int) - Method in interface io.grpc.lb.v1.ClientStatsOrBuilder
-
The list of dropped calls.
- getCallsFinishedWithDropOrBuilderList() - Method in class io.grpc.lb.v1.ClientStats.Builder
-
The list of dropped calls.
- getCallsFinishedWithDropOrBuilderList() - Method in class io.grpc.lb.v1.ClientStats
-
The list of dropped calls.
- getCallsFinishedWithDropOrBuilderList() - Method in interface io.grpc.lb.v1.ClientStatsOrBuilder
-
The list of dropped calls.
- getCallsStarted() - Method in class io.grpc.channelz.v1.ChannelData.Builder
-
The number of calls started on the channel
- getCallsStarted() - Method in class io.grpc.channelz.v1.ChannelData
-
The number of calls started on the channel
- getCallsStarted() - Method in interface io.grpc.channelz.v1.ChannelDataOrBuilder
-
The number of calls started on the channel
- getCallsStarted() - Method in class io.grpc.channelz.v1.ServerData.Builder
-
The number of incoming calls started on the server
- getCallsStarted() - Method in class io.grpc.channelz.v1.ServerData
-
The number of incoming calls started on the server
- getCallsStarted() - Method in interface io.grpc.channelz.v1.ServerDataOrBuilder
-
The number of incoming calls started on the server
- getCallsSucceeded() - Method in class io.grpc.channelz.v1.ChannelData.Builder
-
The number of calls that have completed with an OK status
- getCallsSucceeded() - Method in class io.grpc.channelz.v1.ChannelData
-
The number of calls that have completed with an OK status
- getCallsSucceeded() - Method in interface io.grpc.channelz.v1.ChannelDataOrBuilder
-
The number of calls that have completed with an OK status
- getCallsSucceeded() - Method in class io.grpc.channelz.v1.ServerData.Builder
-
The number of incoming calls that have completed with an OK status
- getCallsSucceeded() - Method in class io.grpc.channelz.v1.ServerData
-
The number of incoming calls that have completed with an OK status
- getCallsSucceeded() - Method in interface io.grpc.channelz.v1.ServerDataOrBuilder
-
The number of incoming calls that have completed with an OK status
- getCandidatesViaHardCoded(Class<T>, Iterable<Class<?>>) - Static method in class io.grpc.InternalServiceProviders
-
Accessor for method.
- getCandidatesViaHardCoded(Class<T>, Iterable<Class<?>>) - Static method in class io.grpc.ServiceProviders
-
Load providers from a hard-coded list.
- getCandidatesViaServiceLoader(Class<T>, ClassLoader) - Static method in class io.grpc.InternalServiceProviders
-
Accessor for method.
- getCandidatesViaServiceLoader(Class<T>, ClassLoader) - Static method in class io.grpc.ServiceProviders
-
Loads service providers for the
klass
service usingServiceLoader
. - getCause() - Method in class io.grpc.Status
-
The underlying cause of an error.
- getCertificateChain() - Method in class io.grpc.TlsChannelCredentials
-
The certificate chain for the client's identity, as a new byte array.
- getCertificateChain() - Method in class io.grpc.TlsServerCredentials
-
The certificate chain for the server's identity, as a new byte array.
- getCertificateChain(String) - Method in class io.grpc.util.AdvancedTlsX509KeyManager
- getChannel() - Method in class io.grpc.channelz.v1.GetChannelResponse.Builder
-
The Channel that corresponds to the requested channel_id.
- getChannel() - Method in class io.grpc.channelz.v1.GetChannelResponse
-
The Channel that corresponds to the requested channel_id.
- getChannel() - Method in interface io.grpc.channelz.v1.GetChannelResponseOrBuilder
-
The Channel that corresponds to the requested channel_id.
- getChannel() - Method in class io.grpc.stub.AbstractStub
-
The underlying channel of the stub.
- getChannel(int) - Method in class io.grpc.channelz.v1.GetTopChannelsResponse.Builder
-
list of channels that the connection detail service knows about.
- getChannel(int) - Method in class io.grpc.channelz.v1.GetTopChannelsResponse
-
list of channels that the connection detail service knows about.
- getChannel(int) - Method in interface io.grpc.channelz.v1.GetTopChannelsResponseOrBuilder
-
list of channels that the connection detail service knows about.
- getChannel(long) - Method in class io.grpc.InternalChannelz
-
Returns a channel.
- getChannel(GetChannelRequest) - Method in class io.grpc.channelz.v1.ChannelzGrpc.ChannelzBlockingStub
-
Returns a single Channel, or else a NOT_FOUND code.
- getChannel(GetChannelRequest) - Method in class io.grpc.channelz.v1.ChannelzGrpc.ChannelzFutureStub
-
Returns a single Channel, or else a NOT_FOUND code.
- getChannel(GetChannelRequest, StreamObserver<GetChannelResponse>) - Method in interface io.grpc.channelz.v1.ChannelzGrpc.AsyncService
-
Returns a single Channel, or else a NOT_FOUND code.
- getChannel(GetChannelRequest, StreamObserver<GetChannelResponse>) - Method in class io.grpc.channelz.v1.ChannelzGrpc.ChannelzStub
-
Returns a single Channel, or else a NOT_FOUND code.
- getChannel(GetChannelRequest, StreamObserver<GetChannelResponse>) - Method in class io.grpc.protobuf.services.ChannelzService
-
Returns a top level channel aka
ManagedChannel
. - getChannel(GetChannelRequest, StreamObserver<GetChannelResponse>) - Method in class io.grpc.services.ChannelzService
-
Deprecated.Returns a top level channel aka
ManagedChannel
. - getChannelBuilder() - Method in class io.grpc.channelz.v1.GetChannelResponse.Builder
-
The Channel that corresponds to the requested channel_id.
- getChannelBuilder() - Method in class io.grpc.ManagedChannelProvider.NewChannelBuilderResult
- getChannelBuilder(int) - Method in class io.grpc.channelz.v1.GetTopChannelsResponse.Builder
-
list of channels that the connection detail service knows about.
- getChannelBuilderList() - Method in class io.grpc.channelz.v1.GetTopChannelsResponse.Builder
-
list of channels that the connection detail service knows about.
- getChannelCount() - Method in class io.grpc.channelz.v1.GetTopChannelsResponse.Builder
-
list of channels that the connection detail service knows about.
- getChannelCount() - Method in class io.grpc.channelz.v1.GetTopChannelsResponse
-
list of channels that the connection detail service knows about.
- getChannelCount() - Method in interface io.grpc.channelz.v1.GetTopChannelsResponseOrBuilder
-
list of channels that the connection detail service knows about.
- getChannelCredentials() - Method in class io.grpc.CompositeChannelCredentials
- getChannelCredentials() - Method in class io.grpc.LoadBalancer.Helper
-
Returns the ChannelCredentials used to construct the channel, without bearer tokens.
- getChannelCredentials() - Method in class io.grpc.util.ForwardingLoadBalancerHelper
- getChannelFieldBuilder() - Method in class io.grpc.channelz.v1.GetChannelResponse.Builder
-
The Channel that corresponds to the requested channel_id.
- getChannelFieldBuilder() - Method in class io.grpc.channelz.v1.GetTopChannelsResponse.Builder
- getChannelId() - Method in class io.grpc.channelz.v1.ChannelRef.Builder
-
The globally unique id for this channel.
- getChannelId() - Method in class io.grpc.channelz.v1.ChannelRef
-
The globally unique id for this channel.
- getChannelId() - Method in interface io.grpc.channelz.v1.ChannelRefOrBuilder
-
The globally unique id for this channel.
- getChannelId() - Method in class io.grpc.channelz.v1.GetChannelRequest.Builder
-
channel_id is the identifier of the specific channel to get.
- getChannelId() - Method in class io.grpc.channelz.v1.GetChannelRequest
-
channel_id is the identifier of the specific channel to get.
- getChannelId() - Method in interface io.grpc.channelz.v1.GetChannelRequestOrBuilder
-
channel_id is the identifier of the specific channel to get.
- getChannelList() - Method in class io.grpc.channelz.v1.GetTopChannelsResponse.Builder
-
list of channels that the connection detail service knows about.
- getChannelList() - Method in class io.grpc.channelz.v1.GetTopChannelsResponse
-
list of channels that the connection detail service knows about.
- getChannelList() - Method in interface io.grpc.channelz.v1.GetTopChannelsResponseOrBuilder
-
list of channels that the connection detail service knows about.
- getChannelLogger() - Method in class io.grpc.internal.ClientTransportFactory.ClientTransportOptions
- getChannelLogger() - Method in class io.grpc.internal.InternalSubchannel
- getChannelLogger() - Method in class io.grpc.internal.ManagedChannelImpl.LbHelperImpl
- getChannelLogger() - Method in class io.grpc.internal.ManagedChannelImpl.SubchannelImpl
- getChannelLogger() - Method in class io.grpc.LoadBalancer.Helper
-
Returns the
ChannelLogger
for the Channel served by this LoadBalancer. - getChannelLogger() - Method in class io.grpc.LoadBalancer.Subchannel
-
Returns a
ChannelLogger
for this Subchannel. - getChannelLogger() - Method in class io.grpc.NameResolver.Args
-
Returns the
ChannelLogger
for the Channel served by this NameResolver. - getChannelLogger() - Method in class io.grpc.util.ForwardingLoadBalancerHelper
- getChannelLogger() - Method in class io.grpc.util.ForwardingSubchannel
- getChannelOrBuilder() - Method in class io.grpc.channelz.v1.GetChannelResponse.Builder
-
The Channel that corresponds to the requested channel_id.
- getChannelOrBuilder() - Method in class io.grpc.channelz.v1.GetChannelResponse
-
The Channel that corresponds to the requested channel_id.
- getChannelOrBuilder() - Method in interface io.grpc.channelz.v1.GetChannelResponseOrBuilder
-
The Channel that corresponds to the requested channel_id.
- getChannelOrBuilder(int) - Method in class io.grpc.channelz.v1.GetTopChannelsResponse.Builder
-
list of channels that the connection detail service knows about.
- getChannelOrBuilder(int) - Method in class io.grpc.channelz.v1.GetTopChannelsResponse
-
list of channels that the connection detail service knows about.
- getChannelOrBuilder(int) - Method in interface io.grpc.channelz.v1.GetTopChannelsResponseOrBuilder
-
list of channels that the connection detail service knows about.
- getChannelOrBuilderList() - Method in class io.grpc.channelz.v1.GetTopChannelsResponse.Builder
-
list of channels that the connection detail service knows about.
- getChannelOrBuilderList() - Method in class io.grpc.channelz.v1.GetTopChannelsResponse
-
list of channels that the connection detail service knows about.
- getChannelOrBuilderList() - Method in interface io.grpc.channelz.v1.GetTopChannelsResponseOrBuilder
-
list of channels that the connection detail service knows about.
- getChannelRef() - Method in class io.grpc.channelz.v1.ChannelTraceEvent.Builder
-
.grpc.channelz.v1.ChannelRef channel_ref = 4;
- getChannelRef() - Method in class io.grpc.channelz.v1.ChannelTraceEvent
-
.grpc.channelz.v1.ChannelRef channel_ref = 4;
- getChannelRef() - Method in interface io.grpc.channelz.v1.ChannelTraceEventOrBuilder
-
.grpc.channelz.v1.ChannelRef channel_ref = 4;
- getChannelRef(int) - Method in class io.grpc.channelz.v1.Channel.Builder
-
There are no ordering guarantees on the order of channel refs.
- getChannelRef(int) - Method in class io.grpc.channelz.v1.Channel
-
There are no ordering guarantees on the order of channel refs.
- getChannelRef(int) - Method in interface io.grpc.channelz.v1.ChannelOrBuilder
-
There are no ordering guarantees on the order of channel refs.
- getChannelRef(int) - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
There are no ordering guarantees on the order of channel refs.
- getChannelRef(int) - Method in class io.grpc.channelz.v1.Subchannel
-
There are no ordering guarantees on the order of channel refs.
- getChannelRef(int) - Method in interface io.grpc.channelz.v1.SubchannelOrBuilder
-
There are no ordering guarantees on the order of channel refs.
- getChannelRefBuilder() - Method in class io.grpc.channelz.v1.ChannelTraceEvent.Builder
-
.grpc.channelz.v1.ChannelRef channel_ref = 4;
- getChannelRefBuilder(int) - Method in class io.grpc.channelz.v1.Channel.Builder
-
There are no ordering guarantees on the order of channel refs.
- getChannelRefBuilder(int) - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
There are no ordering guarantees on the order of channel refs.
- getChannelRefBuilderList() - Method in class io.grpc.channelz.v1.Channel.Builder
-
There are no ordering guarantees on the order of channel refs.
- getChannelRefBuilderList() - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
There are no ordering guarantees on the order of channel refs.
- getChannelRefCount() - Method in class io.grpc.channelz.v1.Channel.Builder
-
There are no ordering guarantees on the order of channel refs.
- getChannelRefCount() - Method in class io.grpc.channelz.v1.Channel
-
There are no ordering guarantees on the order of channel refs.
- getChannelRefCount() - Method in interface io.grpc.channelz.v1.ChannelOrBuilder
-
There are no ordering guarantees on the order of channel refs.
- getChannelRefCount() - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
There are no ordering guarantees on the order of channel refs.
- getChannelRefCount() - Method in class io.grpc.channelz.v1.Subchannel
-
There are no ordering guarantees on the order of channel refs.
- getChannelRefCount() - Method in interface io.grpc.channelz.v1.SubchannelOrBuilder
-
There are no ordering guarantees on the order of channel refs.
- getChannelRefFieldBuilder() - Method in class io.grpc.channelz.v1.Channel.Builder
- getChannelRefFieldBuilder() - Method in class io.grpc.channelz.v1.ChannelTraceEvent.Builder
-
.grpc.channelz.v1.ChannelRef channel_ref = 4;
- getChannelRefFieldBuilder() - Method in class io.grpc.channelz.v1.Subchannel.Builder
- getChannelRefList() - Method in class io.grpc.channelz.v1.Channel.Builder
-
There are no ordering guarantees on the order of channel refs.
- getChannelRefList() - Method in class io.grpc.channelz.v1.Channel
-
There are no ordering guarantees on the order of channel refs.
- getChannelRefList() - Method in interface io.grpc.channelz.v1.ChannelOrBuilder
-
There are no ordering guarantees on the order of channel refs.
- getChannelRefList() - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
There are no ordering guarantees on the order of channel refs.
- getChannelRefList() - Method in class io.grpc.channelz.v1.Subchannel
-
There are no ordering guarantees on the order of channel refs.
- getChannelRefList() - Method in interface io.grpc.channelz.v1.SubchannelOrBuilder
-
There are no ordering guarantees on the order of channel refs.
- getChannelRefOrBuilder() - Method in class io.grpc.channelz.v1.ChannelTraceEvent.Builder
-
.grpc.channelz.v1.ChannelRef channel_ref = 4;
- getChannelRefOrBuilder() - Method in class io.grpc.channelz.v1.ChannelTraceEvent
-
.grpc.channelz.v1.ChannelRef channel_ref = 4;
- getChannelRefOrBuilder() - Method in interface io.grpc.channelz.v1.ChannelTraceEventOrBuilder
-
.grpc.channelz.v1.ChannelRef channel_ref = 4;
- getChannelRefOrBuilder(int) - Method in class io.grpc.channelz.v1.Channel.Builder
-
There are no ordering guarantees on the order of channel refs.
- getChannelRefOrBuilder(int) - Method in class io.grpc.channelz.v1.Channel
-
There are no ordering guarantees on the order of channel refs.
- getChannelRefOrBuilder(int) - Method in interface io.grpc.channelz.v1.ChannelOrBuilder
-
There are no ordering guarantees on the order of channel refs.
- getChannelRefOrBuilder(int) - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
There are no ordering guarantees on the order of channel refs.
- getChannelRefOrBuilder(int) - Method in class io.grpc.channelz.v1.Subchannel
-
There are no ordering guarantees on the order of channel refs.
- getChannelRefOrBuilder(int) - Method in interface io.grpc.channelz.v1.SubchannelOrBuilder
-
There are no ordering guarantees on the order of channel refs.
- getChannelRefOrBuilderList() - Method in class io.grpc.channelz.v1.Channel.Builder
-
There are no ordering guarantees on the order of channel refs.
- getChannelRefOrBuilderList() - Method in class io.grpc.channelz.v1.Channel
-
There are no ordering guarantees on the order of channel refs.
- getChannelRefOrBuilderList() - Method in interface io.grpc.channelz.v1.ChannelOrBuilder
-
There are no ordering guarantees on the order of channel refs.
- getChannelRefOrBuilderList() - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
There are no ordering guarantees on the order of channel refs.
- getChannelRefOrBuilderList() - Method in class io.grpc.channelz.v1.Subchannel
-
There are no ordering guarantees on the order of channel refs.
- getChannelRefOrBuilderList() - Method in interface io.grpc.channelz.v1.SubchannelOrBuilder
-
There are no ordering guarantees on the order of channel refs.
- GetChannelRequest - Class in io.grpc.channelz.v1
-
Protobuf type
grpc.channelz.v1.GetChannelRequest
- GetChannelRequest() - Constructor for class io.grpc.channelz.v1.GetChannelRequest
- GetChannelRequest(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.channelz.v1.GetChannelRequest
- GetChannelRequest.Builder - Class in io.grpc.channelz.v1
-
Protobuf type
grpc.channelz.v1.GetChannelRequest
- GetChannelRequestOrBuilder - Interface in io.grpc.channelz.v1
- GetChannelResponse - Class in io.grpc.channelz.v1
-
Protobuf type
grpc.channelz.v1.GetChannelResponse
- GetChannelResponse() - Constructor for class io.grpc.channelz.v1.GetChannelResponse
- GetChannelResponse(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.channelz.v1.GetChannelResponse
- GetChannelResponse.Builder - Class in io.grpc.channelz.v1
-
Protobuf type
grpc.channelz.v1.GetChannelResponse
- GetChannelResponseOrBuilder - Interface in io.grpc.channelz.v1
- getChannelTarget() - Method in class io.grpc.internal.ManagedChannelImpl.LbHelperImpl
- getChannelTarget() - Method in class io.grpc.LoadBalancer.Helper
-
Returns the target string of the channel, guaranteed to include its scheme.
- getChannelTarget() - Method in class io.grpc.util.ForwardingLoadBalancerHelper
- getChannelz() - Method in class io.grpc.internal.ServerImplBuilder
- getChar(CharSequence) - Method in class io.grpc.netty.AbstractHttp2Headers
- getChar(CharSequence, char) - Method in class io.grpc.netty.AbstractHttp2Headers
- getCharAndRemove(CharSequence) - Method in class io.grpc.netty.AbstractHttp2Headers
- getCharAndRemove(CharSequence, char) - Method in class io.grpc.netty.AbstractHttp2Headers
- getCheckMethod - Static variable in class io.grpc.health.v1.HealthGrpc
- getCheckMethod() - Static method in class io.grpc.health.v1.HealthGrpc
- getChildLbState(Object) - Method in class io.grpc.util.MultiChildLoadBalancer
- getChildLbStateEag(EquivalentAddressGroup) - Method in class io.grpc.util.MultiChildLoadBalancer
- getChildLbStates() - Method in class io.grpc.util.MultiChildLoadBalancer
- getChildPolicyWrapper() - Method in class io.grpc.rls.CachingRlsLbClient.CachedRouteLookupResponse
- getChildPolicyWrapper() - Method in class io.grpc.rls.CachingRlsLbClient.DataCacheEntry
- getChildPolicyWrapper(String) - Method in class io.grpc.rls.CachingRlsLbClient.CachedRouteLookupResponse
- getChildPolicyWrapper(String) - Method in class io.grpc.rls.CachingRlsLbClient.DataCacheEntry
- getChildRefCase() - Method in class io.grpc.channelz.v1.ChannelTraceEvent.Builder
- getChildRefCase() - Method in class io.grpc.channelz.v1.ChannelTraceEvent
- getChildRefCase() - Method in interface io.grpc.channelz.v1.ChannelTraceEventOrBuilder
- getCipherSuiteCase() - Method in class io.grpc.channelz.v1.Security.Tls.Builder
- getCipherSuiteCase() - Method in class io.grpc.channelz.v1.Security.Tls
- getCipherSuiteCase() - Method in interface io.grpc.channelz.v1.Security.TlsOrBuilder
- getClassName(Class<?>) - Static method in class io.grpc.InternalLogId
- getClientAliases(String, Principal[]) - Method in class io.grpc.util.AdvancedTlsX509KeyManager
- getClientAuth() - Method in class io.grpc.TlsServerCredentials
-
Non-
null
setting indicating whether the server should expect a client's identity. - getClientHeader() - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
.grpc.binarylog.v1.ClientHeader client_header = 6;
- getClientHeader() - Method in class io.grpc.binarylog.v1.GrpcLogEntry
-
.grpc.binarylog.v1.ClientHeader client_header = 6;
- getClientHeader() - Method in interface io.grpc.binarylog.v1.GrpcLogEntryOrBuilder
-
.grpc.binarylog.v1.ClientHeader client_header = 6;
- getClientHeaderBuilder() - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
.grpc.binarylog.v1.ClientHeader client_header = 6;
- getClientHeaderFieldBuilder() - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
.grpc.binarylog.v1.ClientHeader client_header = 6;
- getClientHeaderOrBuilder() - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
.grpc.binarylog.v1.ClientHeader client_header = 6;
- getClientHeaderOrBuilder() - Method in class io.grpc.binarylog.v1.GrpcLogEntry
-
.grpc.binarylog.v1.ClientHeader client_header = 6;
- getClientHeaderOrBuilder() - Method in interface io.grpc.binarylog.v1.GrpcLogEntryOrBuilder
-
.grpc.binarylog.v1.ClientHeader client_header = 6;
- getClientInterceptor(long) - Method in class io.grpc.protobuf.services.BinlogHelper
- getClientInterceptor(String, CallOptions) - Method in class io.grpc.protobuf.services.BinaryLogProvider
-
Returns a
ClientInterceptor
for binary logging. - getClientInterceptor(String, CallOptions) - Method in class io.grpc.protobuf.services.BinaryLogProviderImpl
- getClientLanguagesFromChoice(Map<String, ?>) - Static method in class io.grpc.internal.DnsNameResolver
- getClientStats() - Method in class io.grpc.lb.v1.LoadBalanceRequest.Builder
-
The client stats should be periodically reported to the load balancer based on the duration defined in the InitialLoadBalanceResponse.
- getClientStats() - Method in class io.grpc.lb.v1.LoadBalanceRequest
-
The client stats should be periodically reported to the load balancer based on the duration defined in the InitialLoadBalanceResponse.
- getClientStats() - Method in interface io.grpc.lb.v1.LoadBalanceRequestOrBuilder
-
The client stats should be periodically reported to the load balancer based on the duration defined in the InitialLoadBalanceResponse.
- getClientStatsBuilder() - Method in class io.grpc.lb.v1.LoadBalanceRequest.Builder
-
The client stats should be periodically reported to the load balancer based on the duration defined in the InitialLoadBalanceResponse.
- getClientStatsFieldBuilder() - Method in class io.grpc.lb.v1.LoadBalanceRequest.Builder
-
The client stats should be periodically reported to the load balancer based on the duration defined in the InitialLoadBalanceResponse.
- getClientStatsOrBuilder() - Method in class io.grpc.lb.v1.LoadBalanceRequest.Builder
-
The client stats should be periodically reported to the load balancer based on the duration defined in the InitialLoadBalanceResponse.
- getClientStatsOrBuilder() - Method in class io.grpc.lb.v1.LoadBalanceRequest
-
The client stats should be periodically reported to the load balancer based on the duration defined in the InitialLoadBalanceResponse.
- getClientStatsOrBuilder() - Method in interface io.grpc.lb.v1.LoadBalanceRequestOrBuilder
-
The client stats should be periodically reported to the load balancer based on the duration defined in the InitialLoadBalanceResponse.
- getClientStatsReportInterval() - Method in class io.grpc.lb.v1.InitialLoadBalanceResponse.Builder
-
This interval defines how often the client should send the client stats to the load balancer.
- getClientStatsReportInterval() - Method in class io.grpc.lb.v1.InitialLoadBalanceResponse
-
This interval defines how often the client should send the client stats to the load balancer.
- getClientStatsReportInterval() - Method in interface io.grpc.lb.v1.InitialLoadBalanceResponseOrBuilder
-
This interval defines how often the client should send the client stats to the load balancer.
- getClientStatsReportIntervalBuilder() - Method in class io.grpc.lb.v1.InitialLoadBalanceResponse.Builder
-
This interval defines how often the client should send the client stats to the load balancer.
- getClientStatsReportIntervalFieldBuilder() - Method in class io.grpc.lb.v1.InitialLoadBalanceResponse.Builder
-
This interval defines how often the client should send the client stats to the load balancer.
- getClientStatsReportIntervalOrBuilder() - Method in class io.grpc.lb.v1.InitialLoadBalanceResponse.Builder
-
This interval defines how often the client should send the client stats to the load balancer.
- getClientStatsReportIntervalOrBuilder() - Method in class io.grpc.lb.v1.InitialLoadBalanceResponse
-
This interval defines how often the client should send the client stats to the load balancer.
- getClientStatsReportIntervalOrBuilder() - Method in interface io.grpc.lb.v1.InitialLoadBalanceResponseOrBuilder
-
This interval defines how often the client should send the client stats to the load balancer.
- getClientStreamTracers(CallOptions, Metadata, int, boolean) - Static method in class io.grpc.internal.GrpcUtil
-
Gets stream tracers based on CallOptions.
- getCode() - Method in class io.grpc.Status
-
The canonical status code.
- getCompressedBody() - Method in class io.grpc.internal.MessageDeframer
- getCompressor() - Method in class io.grpc.CallOptions
-
Returns the compressor's name.
- getConcludedConnectivityState() - Method in class io.grpc.internal.PickFirstLeafLoadBalancer
- getConfig() - Method in class io.grpc.internal.ServiceConfigUtil.PolicySelection
- getConfig() - Method in class io.grpc.InternalConfigSelector.Result
-
Returns a parsed config.
- getConfig() - Method in class io.grpc.NameResolver.ConfigOrError
-
Returns config if exists, otherwise null.
- getConfigSelector() - Method in class io.grpc.internal.ManagedChannelImpl
- getConfigurators() - Method in class io.grpc.ConfiguratorRegistry
-
Returns a list of the configurators in this registry.
- getConfigurators() - Static method in class io.grpc.InternalConfiguratorRegistry
- getConnectedAddressAttributes() - Method in class io.grpc.internal.InternalSubchannel
-
Return attributes for server address connected by sub channel.
- getConnectedAddressAttributes() - Method in class io.grpc.internal.ManagedChannelImpl.SubchannelImpl
- getConnectedAddressAttributes() - Method in interface io.grpc.InternalSubchannelAddressAttributes
-
Return attributes of the server address connected by sub channel.
- getConnectedAddressAttributes() - Method in class io.grpc.LoadBalancer.Subchannel
-
(Internal use only) returns attributes of the address subchannel is connected to.
- getConnectedAddressAttributes() - Method in class io.grpc.util.ForwardingSubchannel
- getConstantKeys() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
-
Deprecated.
- getConstantKeys() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder
-
Deprecated.
- getConstantKeys() - Method in interface io.grpc.lookup.v1.GrpcKeyBuilderOrBuilder
-
Deprecated.
- getConstantKeys() - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
-
Deprecated.
- getConstantKeys() - Method in class io.grpc.lookup.v1.HttpKeyBuilder
-
Deprecated.
- getConstantKeys() - Method in interface io.grpc.lookup.v1.HttpKeyBuilderOrBuilder
-
Deprecated.
- getConstantKeysCount() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
- getConstantKeysCount() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder
- getConstantKeysCount() - Method in interface io.grpc.lookup.v1.GrpcKeyBuilderOrBuilder
-
You can optionally set one or more specific key/value pairs to be added to the key_map.
- getConstantKeysCount() - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
- getConstantKeysCount() - Method in class io.grpc.lookup.v1.HttpKeyBuilder
- getConstantKeysCount() - Method in interface io.grpc.lookup.v1.HttpKeyBuilderOrBuilder
-
You can optionally set one or more specific key/value pairs to be added to the key_map.
- getConstantKeysMap() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
-
You can optionally set one or more specific key/value pairs to be added to the key_map.
- getConstantKeysMap() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder
-
You can optionally set one or more specific key/value pairs to be added to the key_map.
- getConstantKeysMap() - Method in interface io.grpc.lookup.v1.GrpcKeyBuilderOrBuilder
-
You can optionally set one or more specific key/value pairs to be added to the key_map.
- getConstantKeysMap() - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
-
You can optionally set one or more specific key/value pairs to be added to the key_map.
- getConstantKeysMap() - Method in class io.grpc.lookup.v1.HttpKeyBuilder
-
You can optionally set one or more specific key/value pairs to be added to the key_map.
- getConstantKeysMap() - Method in interface io.grpc.lookup.v1.HttpKeyBuilderOrBuilder
-
You can optionally set one or more specific key/value pairs to be added to the key_map.
- getConstantKeysOrDefault(String, String) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
-
You can optionally set one or more specific key/value pairs to be added to the key_map.
- getConstantKeysOrDefault(String, String) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder
-
You can optionally set one or more specific key/value pairs to be added to the key_map.
- getConstantKeysOrDefault(String, String) - Method in interface io.grpc.lookup.v1.GrpcKeyBuilderOrBuilder
-
You can optionally set one or more specific key/value pairs to be added to the key_map.
- getConstantKeysOrDefault(String, String) - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
-
You can optionally set one or more specific key/value pairs to be added to the key_map.
- getConstantKeysOrDefault(String, String) - Method in class io.grpc.lookup.v1.HttpKeyBuilder
-
You can optionally set one or more specific key/value pairs to be added to the key_map.
- getConstantKeysOrDefault(String, String) - Method in interface io.grpc.lookup.v1.HttpKeyBuilderOrBuilder
-
You can optionally set one or more specific key/value pairs to be added to the key_map.
- getConstantKeysOrThrow(String) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
-
You can optionally set one or more specific key/value pairs to be added to the key_map.
- getConstantKeysOrThrow(String) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder
-
You can optionally set one or more specific key/value pairs to be added to the key_map.
- getConstantKeysOrThrow(String) - Method in interface io.grpc.lookup.v1.GrpcKeyBuilderOrBuilder
-
You can optionally set one or more specific key/value pairs to be added to the key_map.
- getConstantKeysOrThrow(String) - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
-
You can optionally set one or more specific key/value pairs to be added to the key_map.
- getConstantKeysOrThrow(String) - Method in class io.grpc.lookup.v1.HttpKeyBuilder
-
You can optionally set one or more specific key/value pairs to be added to the key_map.
- getConstantKeysOrThrow(String) - Method in interface io.grpc.lookup.v1.HttpKeyBuilderOrBuilder
-
You can optionally set one or more specific key/value pairs to be added to the key_map.
- getContainingType() - Method in class io.grpc.reflection.v1.ExtensionRequest.Builder
-
Fully-qualified type name.
- getContainingType() - Method in class io.grpc.reflection.v1.ExtensionRequest
-
Fully-qualified type name.
- getContainingType() - Method in interface io.grpc.reflection.v1.ExtensionRequestOrBuilder
-
Fully-qualified type name.
- getContainingType() - Method in class io.grpc.reflection.v1alpha.ExtensionRequest.Builder
-
Fully-qualified type name.
- getContainingType() - Method in class io.grpc.reflection.v1alpha.ExtensionRequest
-
Fully-qualified type name.
- getContainingType() - Method in interface io.grpc.reflection.v1alpha.ExtensionRequestOrBuilder
-
Fully-qualified type name.
- getContainingTypeBytes() - Method in class io.grpc.reflection.v1.ExtensionRequest.Builder
-
Fully-qualified type name.
- getContainingTypeBytes() - Method in class io.grpc.reflection.v1.ExtensionRequest
-
Fully-qualified type name.
- getContainingTypeBytes() - Method in interface io.grpc.reflection.v1.ExtensionRequestOrBuilder
-
Fully-qualified type name.
- getContainingTypeBytes() - Method in class io.grpc.reflection.v1alpha.ExtensionRequest.Builder
-
Fully-qualified type name.
- getContainingTypeBytes() - Method in class io.grpc.reflection.v1alpha.ExtensionRequest
-
Fully-qualified type name.
- getContainingTypeBytes() - Method in interface io.grpc.reflection.v1alpha.ExtensionRequestOrBuilder
-
Fully-qualified type name.
- getCpuUtilization() - Method in class io.grpc.services.MetricReport
- getCreationTimestamp() - Method in class io.grpc.channelz.v1.ChannelTrace.Builder
-
Time that this channel was created.
- getCreationTimestamp() - Method in class io.grpc.channelz.v1.ChannelTrace
-
Time that this channel was created.
- getCreationTimestamp() - Method in interface io.grpc.channelz.v1.ChannelTraceOrBuilder
-
Time that this channel was created.
- getCreationTimestampBuilder() - Method in class io.grpc.channelz.v1.ChannelTrace.Builder
-
Time that this channel was created.
- getCreationTimestampFieldBuilder() - Method in class io.grpc.channelz.v1.ChannelTrace.Builder
-
Time that this channel was created.
- getCreationTimestampOrBuilder() - Method in class io.grpc.channelz.v1.ChannelTrace.Builder
-
Time that this channel was created.
- getCreationTimestampOrBuilder() - Method in class io.grpc.channelz.v1.ChannelTrace
-
Time that this channel was created.
- getCreationTimestampOrBuilder() - Method in interface io.grpc.channelz.v1.ChannelTraceOrBuilder
-
Time that this channel was created.
- getCredentials() - Method in class io.grpc.CallOptions
-
Returns the call credentials.
- getCredentialsList() - Method in class io.grpc.ChoiceChannelCredentials
-
Non-empty list of credentials, in preference order.
- getCredentialsList() - Method in class io.grpc.ChoiceServerCredentials
-
Non-empty list of credentials, in preference order.
- getCurrent() - Method in class io.grpc.internal.ServiceConfigState
-
Gets the current service config or error.
- getCurrent() - Static method in class io.grpc.services.CallMetricRecorder
-
Returns the call metric recorder attached to the current
Context
. - getCurrentAddress() - Method in class io.grpc.internal.InternalSubchannel.Index
- getCurrentAddress() - Method in class io.grpc.internal.PickFirstLeafLoadBalancer.Index
- getCurrentEagAsList() - Method in class io.grpc.internal.PickFirstLeafLoadBalancer.Index
- getCurrentEagAttributes() - Method in class io.grpc.internal.InternalSubchannel.Index
- getCurrentEagAttributes() - Method in class io.grpc.internal.PickFirstLeafLoadBalancer.Index
- getCurrentPicker() - Method in class io.grpc.util.MultiChildLoadBalancer.ChildLbState
- getCurrentState() - Method in class io.grpc.util.MultiChildLoadBalancer.ChildLbState
- getData() - Method in class io.grpc.binarylog.v1.Message.Builder
-
May be truncated or omitted.
- getData() - Method in class io.grpc.binarylog.v1.Message
-
May be truncated or omitted.
- getData() - Method in interface io.grpc.binarylog.v1.MessageOrBuilder
-
May be truncated or omitted.
- getData() - Method in class io.grpc.channelz.v1.Channel.Builder
-
Data specific to this channel.
- getData() - Method in class io.grpc.channelz.v1.Channel
-
Data specific to this channel.
- getData() - Method in interface io.grpc.channelz.v1.ChannelOrBuilder
-
Data specific to this channel.
- getData() - Method in class io.grpc.channelz.v1.Server.Builder
-
The associated data of the Server.
- getData() - Method in class io.grpc.channelz.v1.Server
-
The associated data of the Server.
- getData() - Method in interface io.grpc.channelz.v1.ServerOrBuilder
-
The associated data of the Server.
- getData() - Method in class io.grpc.channelz.v1.Socket.Builder
-
Data specific to this Socket.
- getData() - Method in class io.grpc.channelz.v1.Socket
-
Data specific to this Socket.
- getData() - Method in interface io.grpc.channelz.v1.SocketOrBuilder
-
Data specific to this Socket.
- getData() - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
Data specific to this channel.
- getData() - Method in class io.grpc.channelz.v1.Subchannel
-
Data specific to this channel.
- getData() - Method in interface io.grpc.channelz.v1.SubchannelOrBuilder
-
Data specific to this channel.
- getDataBuilder() - Method in class io.grpc.channelz.v1.Channel.Builder
-
Data specific to this channel.
- getDataBuilder() - Method in class io.grpc.channelz.v1.Server.Builder
-
The associated data of the Server.
- getDataBuilder() - Method in class io.grpc.channelz.v1.Socket.Builder
-
Data specific to this Socket.
- getDataBuilder() - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
Data specific to this channel.
- getDataFieldBuilder() - Method in class io.grpc.channelz.v1.Channel.Builder
-
Data specific to this channel.
- getDataFieldBuilder() - Method in class io.grpc.channelz.v1.Server.Builder
-
The associated data of the Server.
- getDataFieldBuilder() - Method in class io.grpc.channelz.v1.Socket.Builder
-
Data specific to this Socket.
- getDataFieldBuilder() - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
Data specific to this channel.
- getDataOrBuilder() - Method in class io.grpc.channelz.v1.Channel.Builder
-
Data specific to this channel.
- getDataOrBuilder() - Method in class io.grpc.channelz.v1.Channel
-
Data specific to this channel.
- getDataOrBuilder() - Method in interface io.grpc.channelz.v1.ChannelOrBuilder
-
Data specific to this channel.
- getDataOrBuilder() - Method in class io.grpc.channelz.v1.Server.Builder
-
The associated data of the Server.
- getDataOrBuilder() - Method in class io.grpc.channelz.v1.Server
-
The associated data of the Server.
- getDataOrBuilder() - Method in interface io.grpc.channelz.v1.ServerOrBuilder
-
The associated data of the Server.
- getDataOrBuilder() - Method in class io.grpc.channelz.v1.Socket.Builder
-
Data specific to this Socket.
- getDataOrBuilder() - Method in class io.grpc.channelz.v1.Socket
-
Data specific to this Socket.
- getDataOrBuilder() - Method in interface io.grpc.channelz.v1.SocketOrBuilder
-
Data specific to this Socket.
- getDataOrBuilder() - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
Data specific to this channel.
- getDataOrBuilder() - Method in class io.grpc.channelz.v1.Subchannel
-
Data specific to this channel.
- getDataOrBuilder() - Method in interface io.grpc.channelz.v1.SubchannelOrBuilder
-
Data specific to this channel.
- getDataSincePing() - Method in class io.grpc.netty.AbstractNettyHandler.FlowControlPinger
- getDeadline() - Method in class io.grpc.CallOptions
-
Returns the deadline or
null
if the deadline is not set. - getDeadline() - Method in class io.grpc.Context.CancellableContext
- getDeadline() - Method in class io.grpc.Context
-
A context may have an associated
Deadline
at which it will be automatically cancelled. - getDefault() - Method in class io.grpc.CallOptions.Key
-
Returns the user supplied default value for this key.
- getDefault() - Method in class io.grpc.LoadBalancer.CreateSubchannelArgs.Key
-
Returns the user supplied default value for this key.
- getDefault() - Static method in class io.grpc.netty.InternalProtocolNegotiationEvent
- getDefaultConfigSelector() - Method in class io.grpc.internal.ManagedChannelServiceConfig
-
Used as a fallback per-RPC config supplier when the attributes value of
InternalConfigSelector.KEY
is not available. - getDefaultFactory() - Static method in class io.grpc.internal.CallTracer
- getDefaultFactory() - Static method in class io.grpc.internal.TransportTracer
- getDefaultInstance() - Static method in class io.grpc.binarylog.v1.Address
- getDefaultInstance() - Static method in class io.grpc.binarylog.v1.ClientHeader
- getDefaultInstance() - Static method in class io.grpc.binarylog.v1.GrpcLogEntry
- getDefaultInstance() - Static method in class io.grpc.binarylog.v1.Message
- getDefaultInstance() - Static method in class io.grpc.binarylog.v1.Metadata
- getDefaultInstance() - Static method in class io.grpc.binarylog.v1.MetadataEntry
- getDefaultInstance() - Static method in class io.grpc.binarylog.v1.ServerHeader
- getDefaultInstance() - Static method in class io.grpc.binarylog.v1.Trailer
- getDefaultInstance() - Static method in class io.grpc.channelz.v1.Address
- getDefaultInstance() - Static method in class io.grpc.channelz.v1.Address.OtherAddress
- getDefaultInstance() - Static method in class io.grpc.channelz.v1.Address.TcpIpAddress
- getDefaultInstance() - Static method in class io.grpc.channelz.v1.Address.UdsAddress
- getDefaultInstance() - Static method in class io.grpc.channelz.v1.Channel
- getDefaultInstance() - Static method in class io.grpc.channelz.v1.ChannelConnectivityState
- getDefaultInstance() - Static method in class io.grpc.channelz.v1.ChannelData
- getDefaultInstance() - Static method in class io.grpc.channelz.v1.ChannelRef
- getDefaultInstance() - Static method in class io.grpc.channelz.v1.ChannelTrace
- getDefaultInstance() - Static method in class io.grpc.channelz.v1.ChannelTraceEvent
- getDefaultInstance() - Static method in class io.grpc.channelz.v1.GetChannelRequest
- getDefaultInstance() - Static method in class io.grpc.channelz.v1.GetChannelResponse
- getDefaultInstance() - Static method in class io.grpc.channelz.v1.GetServerRequest
- getDefaultInstance() - Static method in class io.grpc.channelz.v1.GetServerResponse
- getDefaultInstance() - Static method in class io.grpc.channelz.v1.GetServerSocketsRequest
- getDefaultInstance() - Static method in class io.grpc.channelz.v1.GetServerSocketsResponse
- getDefaultInstance() - Static method in class io.grpc.channelz.v1.GetServersRequest
- getDefaultInstance() - Static method in class io.grpc.channelz.v1.GetServersResponse
- getDefaultInstance() - Static method in class io.grpc.channelz.v1.GetSocketRequest
- getDefaultInstance() - Static method in class io.grpc.channelz.v1.GetSocketResponse
- getDefaultInstance() - Static method in class io.grpc.channelz.v1.GetSubchannelRequest
- getDefaultInstance() - Static method in class io.grpc.channelz.v1.GetSubchannelResponse
- getDefaultInstance() - Static method in class io.grpc.channelz.v1.GetTopChannelsRequest
- getDefaultInstance() - Static method in class io.grpc.channelz.v1.GetTopChannelsResponse
- getDefaultInstance() - Static method in class io.grpc.channelz.v1.Security
- getDefaultInstance() - Static method in class io.grpc.channelz.v1.Security.OtherSecurity
- getDefaultInstance() - Static method in class io.grpc.channelz.v1.Security.Tls
- getDefaultInstance() - Static method in class io.grpc.channelz.v1.Server
- getDefaultInstance() - Static method in class io.grpc.channelz.v1.ServerData
- getDefaultInstance() - Static method in class io.grpc.channelz.v1.ServerRef
- getDefaultInstance() - Static method in class io.grpc.channelz.v1.Socket
- getDefaultInstance() - Static method in class io.grpc.channelz.v1.SocketData
- getDefaultInstance() - Static method in class io.grpc.channelz.v1.SocketOption
- getDefaultInstance() - Static method in class io.grpc.channelz.v1.SocketOptionLinger
- getDefaultInstance() - Static method in class io.grpc.channelz.v1.SocketOptionTcpInfo
- getDefaultInstance() - Static method in class io.grpc.channelz.v1.SocketOptionTimeout
- getDefaultInstance() - Static method in class io.grpc.channelz.v1.SocketRef
- getDefaultInstance() - Static method in class io.grpc.channelz.v1.Subchannel
- getDefaultInstance() - Static method in class io.grpc.channelz.v1.SubchannelRef
- 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
- getDefaultInstance() - Static method in class io.grpc.health.v1.HealthCheckRequest
- getDefaultInstance() - Static method in class io.grpc.health.v1.HealthCheckResponse
- getDefaultInstance() - Static method in class io.grpc.lb.v1.ClientStats
- getDefaultInstance() - Static method in class io.grpc.lb.v1.ClientStatsPerToken
- getDefaultInstance() - Static method in class io.grpc.lb.v1.FallbackResponse
- getDefaultInstance() - Static method in class io.grpc.lb.v1.InitialLoadBalanceRequest
- getDefaultInstance() - Static method in class io.grpc.lb.v1.InitialLoadBalanceResponse
- getDefaultInstance() - Static method in class io.grpc.lb.v1.LoadBalanceRequest
- getDefaultInstance() - Static method in class io.grpc.lb.v1.LoadBalanceResponse
- getDefaultInstance() - Static method in class io.grpc.lb.v1.Server
- getDefaultInstance() - Static method in class io.grpc.lb.v1.ServerList
- getDefaultInstance() - Static method in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys
- getDefaultInstance() - Static method in class io.grpc.lookup.v1.GrpcKeyBuilder
- getDefaultInstance() - Static method in class io.grpc.lookup.v1.GrpcKeyBuilder.Name
- getDefaultInstance() - Static method in class io.grpc.lookup.v1.HttpKeyBuilder
- getDefaultInstance() - Static method in class io.grpc.lookup.v1.NameMatcher
- getDefaultInstance() - Static method in class io.grpc.lookup.v1.RouteLookupClusterSpecifier
- getDefaultInstance() - Static method in class io.grpc.lookup.v1.RouteLookupConfig
- getDefaultInstance() - Static method in class io.grpc.lookup.v1.RouteLookupRequest
- getDefaultInstance() - Static method in class io.grpc.lookup.v1.RouteLookupResponse
- getDefaultInstance() - Static method in class io.grpc.reflection.v1.ErrorResponse
- getDefaultInstance() - Static method in class io.grpc.reflection.v1.ExtensionNumberResponse
- getDefaultInstance() - Static method in class io.grpc.reflection.v1.ExtensionRequest
- getDefaultInstance() - Static method in class io.grpc.reflection.v1.FileDescriptorResponse
- getDefaultInstance() - Static method in class io.grpc.reflection.v1.ListServiceResponse
- getDefaultInstance() - Static method in class io.grpc.reflection.v1.ServerReflectionRequest
- getDefaultInstance() - Static method in class io.grpc.reflection.v1.ServerReflectionResponse
- getDefaultInstance() - Static method in class io.grpc.reflection.v1.ServiceResponse
- getDefaultInstance() - Static method in class io.grpc.reflection.v1alpha.ErrorResponse
- getDefaultInstance() - Static method in class io.grpc.reflection.v1alpha.ExtensionNumberResponse
- getDefaultInstance() - Static method in class io.grpc.reflection.v1alpha.ExtensionRequest
- getDefaultInstance() - Static method in class io.grpc.reflection.v1alpha.FileDescriptorResponse
- getDefaultInstance() - Static method in class io.grpc.reflection.v1alpha.ListServiceResponse
- getDefaultInstance() - Static method in class io.grpc.reflection.v1alpha.ServerReflectionRequest
- getDefaultInstance() - Static method in class io.grpc.reflection.v1alpha.ServerReflectionResponse
- getDefaultInstance() - Static method in class io.grpc.reflection.v1alpha.ServiceResponse
- getDefaultInstanceForType() - Method in class io.grpc.binarylog.v1.Address.Builder
- getDefaultInstanceForType() - Method in class io.grpc.binarylog.v1.Address
- getDefaultInstanceForType() - Method in class io.grpc.binarylog.v1.ClientHeader.Builder
- getDefaultInstanceForType() - Method in class io.grpc.binarylog.v1.ClientHeader
- getDefaultInstanceForType() - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
- getDefaultInstanceForType() - Method in class io.grpc.binarylog.v1.GrpcLogEntry
- getDefaultInstanceForType() - Method in class io.grpc.binarylog.v1.Message.Builder
- getDefaultInstanceForType() - Method in class io.grpc.binarylog.v1.Message
- getDefaultInstanceForType() - Method in class io.grpc.binarylog.v1.Metadata.Builder
- getDefaultInstanceForType() - Method in class io.grpc.binarylog.v1.Metadata
- getDefaultInstanceForType() - Method in class io.grpc.binarylog.v1.MetadataEntry.Builder
- getDefaultInstanceForType() - Method in class io.grpc.binarylog.v1.MetadataEntry
- getDefaultInstanceForType() - Method in class io.grpc.binarylog.v1.ServerHeader.Builder
- getDefaultInstanceForType() - Method in class io.grpc.binarylog.v1.ServerHeader
- getDefaultInstanceForType() - Method in class io.grpc.binarylog.v1.Trailer.Builder
- getDefaultInstanceForType() - Method in class io.grpc.binarylog.v1.Trailer
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.Address.Builder
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.Address
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.Address.OtherAddress.Builder
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.Address.OtherAddress
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.Address.TcpIpAddress.Builder
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.Address.TcpIpAddress
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.Address.UdsAddress.Builder
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.Address.UdsAddress
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.Channel.Builder
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.Channel
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.ChannelConnectivityState.Builder
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.ChannelConnectivityState
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.ChannelData.Builder
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.ChannelData
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.ChannelRef.Builder
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.ChannelRef
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.ChannelTrace.Builder
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.ChannelTrace
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.ChannelTraceEvent.Builder
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.ChannelTraceEvent
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.GetChannelRequest.Builder
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.GetChannelRequest
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.GetChannelResponse.Builder
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.GetChannelResponse
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.GetServerRequest.Builder
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.GetServerRequest
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.GetServerResponse.Builder
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.GetServerResponse
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.GetServerSocketsRequest.Builder
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.GetServerSocketsRequest
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.GetServerSocketsResponse.Builder
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.GetServerSocketsResponse
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.GetServersRequest.Builder
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.GetServersRequest
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.GetServersResponse.Builder
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.GetServersResponse
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.GetSocketRequest.Builder
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.GetSocketRequest
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.GetSocketResponse.Builder
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.GetSocketResponse
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.GetSubchannelRequest.Builder
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.GetSubchannelRequest
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.GetSubchannelResponse.Builder
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.GetSubchannelResponse
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.GetTopChannelsRequest.Builder
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.GetTopChannelsRequest
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.GetTopChannelsResponse.Builder
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.GetTopChannelsResponse
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.Security.Builder
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.Security
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.Security.OtherSecurity.Builder
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.Security.OtherSecurity
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.Security.Tls.Builder
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.Security.Tls
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.Server.Builder
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.Server
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.ServerData.Builder
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.ServerData
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.ServerRef.Builder
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.ServerRef
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.Socket.Builder
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.Socket
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.SocketData.Builder
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.SocketData
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.SocketOption.Builder
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.SocketOption
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.SocketOptionLinger.Builder
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.SocketOptionLinger
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.SocketOptionTimeout.Builder
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.SocketOptionTimeout
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.SocketRef.Builder
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.SocketRef
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.Subchannel.Builder
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.Subchannel
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.SubchannelRef.Builder
- getDefaultInstanceForType() - Method in class io.grpc.channelz.v1.SubchannelRef
- getDefaultInstanceForType() - Method in class io.grpc.health.v1.HealthCheckRequest.Builder
- getDefaultInstanceForType() - Method in class io.grpc.health.v1.HealthCheckRequest
- getDefaultInstanceForType() - Method in class io.grpc.health.v1.HealthCheckResponse.Builder
- getDefaultInstanceForType() - Method in class io.grpc.health.v1.HealthCheckResponse
- getDefaultInstanceForType() - Method in class io.grpc.lb.v1.ClientStats.Builder
- getDefaultInstanceForType() - Method in class io.grpc.lb.v1.ClientStats
- getDefaultInstanceForType() - Method in class io.grpc.lb.v1.ClientStatsPerToken.Builder
- getDefaultInstanceForType() - Method in class io.grpc.lb.v1.ClientStatsPerToken
- getDefaultInstanceForType() - Method in class io.grpc.lb.v1.FallbackResponse.Builder
- getDefaultInstanceForType() - Method in class io.grpc.lb.v1.FallbackResponse
- getDefaultInstanceForType() - Method in class io.grpc.lb.v1.InitialLoadBalanceRequest.Builder
- getDefaultInstanceForType() - Method in class io.grpc.lb.v1.InitialLoadBalanceRequest
- getDefaultInstanceForType() - Method in class io.grpc.lb.v1.InitialLoadBalanceResponse.Builder
- getDefaultInstanceForType() - Method in class io.grpc.lb.v1.InitialLoadBalanceResponse
- getDefaultInstanceForType() - Method in class io.grpc.lb.v1.LoadBalanceRequest.Builder
- getDefaultInstanceForType() - Method in class io.grpc.lb.v1.LoadBalanceRequest
- getDefaultInstanceForType() - Method in class io.grpc.lb.v1.LoadBalanceResponse.Builder
- getDefaultInstanceForType() - Method in class io.grpc.lb.v1.LoadBalanceResponse
- getDefaultInstanceForType() - Method in class io.grpc.lb.v1.Server.Builder
- getDefaultInstanceForType() - Method in class io.grpc.lb.v1.Server
- getDefaultInstanceForType() - Method in class io.grpc.lb.v1.ServerList.Builder
- getDefaultInstanceForType() - Method in class io.grpc.lb.v1.ServerList
- getDefaultInstanceForType() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
- getDefaultInstanceForType() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys.Builder
- getDefaultInstanceForType() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys
- getDefaultInstanceForType() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder
- getDefaultInstanceForType() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Name.Builder
- getDefaultInstanceForType() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Name
- getDefaultInstanceForType() - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
- getDefaultInstanceForType() - Method in class io.grpc.lookup.v1.HttpKeyBuilder
- getDefaultInstanceForType() - Method in class io.grpc.lookup.v1.NameMatcher.Builder
- getDefaultInstanceForType() - Method in class io.grpc.lookup.v1.NameMatcher
- getDefaultInstanceForType() - Method in class io.grpc.lookup.v1.RouteLookupClusterSpecifier.Builder
- getDefaultInstanceForType() - Method in class io.grpc.lookup.v1.RouteLookupClusterSpecifier
- getDefaultInstanceForType() - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
- getDefaultInstanceForType() - Method in class io.grpc.lookup.v1.RouteLookupConfig
- getDefaultInstanceForType() - Method in class io.grpc.lookup.v1.RouteLookupRequest.Builder
- getDefaultInstanceForType() - Method in class io.grpc.lookup.v1.RouteLookupRequest
- getDefaultInstanceForType() - Method in class io.grpc.lookup.v1.RouteLookupResponse.Builder
- getDefaultInstanceForType() - Method in class io.grpc.lookup.v1.RouteLookupResponse
- getDefaultInstanceForType() - Method in class io.grpc.reflection.v1.ErrorResponse.Builder
- getDefaultInstanceForType() - Method in class io.grpc.reflection.v1.ErrorResponse
- getDefaultInstanceForType() - Method in class io.grpc.reflection.v1.ExtensionNumberResponse.Builder
- getDefaultInstanceForType() - Method in class io.grpc.reflection.v1.ExtensionNumberResponse
- getDefaultInstanceForType() - Method in class io.grpc.reflection.v1.ExtensionRequest.Builder
- getDefaultInstanceForType() - Method in class io.grpc.reflection.v1.ExtensionRequest
- getDefaultInstanceForType() - Method in class io.grpc.reflection.v1.FileDescriptorResponse.Builder
- getDefaultInstanceForType() - Method in class io.grpc.reflection.v1.FileDescriptorResponse
- getDefaultInstanceForType() - Method in class io.grpc.reflection.v1.ListServiceResponse.Builder
- getDefaultInstanceForType() - Method in class io.grpc.reflection.v1.ListServiceResponse
- getDefaultInstanceForType() - Method in class io.grpc.reflection.v1.ServerReflectionRequest.Builder
- getDefaultInstanceForType() - Method in class io.grpc.reflection.v1.ServerReflectionRequest
- getDefaultInstanceForType() - Method in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
- getDefaultInstanceForType() - Method in class io.grpc.reflection.v1.ServerReflectionResponse
- getDefaultInstanceForType() - Method in class io.grpc.reflection.v1.ServiceResponse.Builder
- getDefaultInstanceForType() - Method in class io.grpc.reflection.v1.ServiceResponse
- getDefaultInstanceForType() - Method in class io.grpc.reflection.v1alpha.ErrorResponse.Builder
- getDefaultInstanceForType() - Method in class io.grpc.reflection.v1alpha.ErrorResponse
- getDefaultInstanceForType() - Method in class io.grpc.reflection.v1alpha.ExtensionNumberResponse.Builder
- getDefaultInstanceForType() - Method in class io.grpc.reflection.v1alpha.ExtensionNumberResponse
- getDefaultInstanceForType() - Method in class io.grpc.reflection.v1alpha.ExtensionRequest.Builder
- getDefaultInstanceForType() - Method in class io.grpc.reflection.v1alpha.ExtensionRequest
- getDefaultInstanceForType() - Method in class io.grpc.reflection.v1alpha.FileDescriptorResponse.Builder
- getDefaultInstanceForType() - Method in class io.grpc.reflection.v1alpha.FileDescriptorResponse
- getDefaultInstanceForType() - Method in class io.grpc.reflection.v1alpha.ListServiceResponse.Builder
- getDefaultInstanceForType() - Method in class io.grpc.reflection.v1alpha.ListServiceResponse
- getDefaultInstanceForType() - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest.Builder
- getDefaultInstanceForType() - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest
- getDefaultInstanceForType() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
- getDefaultInstanceForType() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse
- getDefaultInstanceForType() - Method in class io.grpc.reflection.v1alpha.ServiceResponse.Builder
- getDefaultInstanceForType() - Method in class io.grpc.reflection.v1alpha.ServiceResponse
- getDefaultPort() - Method in interface io.grpc.internal.ManagedChannelImplBuilder.ChannelBuilderDefaultPortProvider
- getDefaultPort() - Method in class io.grpc.internal.ManagedChannelImplBuilder.FixedPortProvider
- getDefaultPort() - Method in class io.grpc.internal.ManagedChannelImplBuilder
-
Returns a default port to
NameResolver
for use in cases where the target string doesn't include a port. - getDefaultPort() - Method in class io.grpc.internal.ManagedChannelImplBuilder.ManagedChannelDefaultPortProvider
- getDefaultPort() - Method in class io.grpc.NameResolver.Args
-
The port number used in case the target or the underlying naming system doesn't provide a port number.
- getDefaultPort() - Method in class io.grpc.netty.NettyChannelBuilder.DefaultProtocolNegotiator
- getDefaultPort() - Method in class io.grpc.netty.NettyChannelBuilder
- getDefaultPort() - Method in class io.grpc.netty.NettyChannelBuilder.NettyChannelDefaultPortProvider
- getDefaultPort() - Method in interface io.grpc.netty.ProtocolNegotiator.ClientFactory
-
Returns the implicit port to use if no port was specified explicitly by the user.
- getDefaultPort() - Method in class io.grpc.netty.ProtocolNegotiators.PlaintextProtocolNegotiatorClientFactory
- getDefaultPort() - Method in class io.grpc.netty.ProtocolNegotiators.PlaintextUpgradeProtocolNegotiatorClientFactory
- getDefaultPort() - Method in class io.grpc.netty.ProtocolNegotiators.TlsProtocolNegotiatorClientFactory
- getDefaultRegistry() - Static method in class io.grpc.ConfiguratorRegistry
-
Returns the default global instance of the configurator registry.
- getDefaultRegistry() - Static method in class io.grpc.LoadBalancerRegistry
-
Returns the default registry that loads providers via the Java service loader mechanism.
- getDefaultRegistry() - Static method in class io.grpc.ManagedChannelRegistry
-
Returns the default registry that loads providers via the Java service loader mechanism.
- getDefaultRegistry() - Static method in class io.grpc.MetricInstrumentRegistry
-
Returns the default metric instrument registry.
- getDefaultRegistry() - Static method in class io.grpc.NameResolverRegistry
-
Returns the default registry that loads providers via the Java service loader mechanism.
- getDefaultRegistry() - Static method in class io.grpc.ServerRegistry
-
Returns the default registry that loads providers via the Java service loader mechanism.
- getDefaultScheme() - Method in class io.grpc.grpclb.SecretGrpclbNameResolverProvider.Provider
- getDefaultScheme() - Method in class io.grpc.internal.DnsNameResolverProvider
- getDefaultScheme() - Method in class io.grpc.internal.ManagedChannelImplBuilder.DirectAddressNameResolverProvider
- getDefaultScheme() - Method in class io.grpc.internal.NameResolverFactoryToProviderFacade
- getDefaultScheme() - Method in class io.grpc.NameResolver.Factory
-
Returns the default scheme, which will be used to construct a URI when
ManagedChannelBuilder.forTarget(String)
is given an authority string instead of a compliant URI. - getDefaultScheme() - Method in class io.grpc.NameResolverRegistry
- getDefaultScheme() - Method in class io.grpc.NameResolverRegistry.NameResolverFactory
- getDefaultScheme() - Method in class io.grpc.netty.UdsNameResolverProvider
- getDefaultTarget() - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
This value provides a default target to use if needed.
- getDefaultTarget() - Method in class io.grpc.lookup.v1.RouteLookupConfig
-
This value provides a default target to use if needed.
- getDefaultTarget() - Method in interface io.grpc.lookup.v1.RouteLookupConfigOrBuilder
-
This value provides a default target to use if needed.
- getDefaultTargetBytes() - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
This value provides a default target to use if needed.
- getDefaultTargetBytes() - Method in class io.grpc.lookup.v1.RouteLookupConfig
-
This value provides a default target to use if needed.
- getDefaultTargetBytes() - Method in interface io.grpc.lookup.v1.RouteLookupConfigOrBuilder
-
This value provides a default target to use if needed.
- getDelegate() - Method in class io.grpc.internal.AutoConfiguredLoadBalancerFactory.AutoConfiguredLoadBalancer
- getDelegateProvider() - Method in class io.grpc.internal.AutoConfiguredLoadBalancerFactory.AutoConfiguredLoadBalancer
- getDescription() - Method in class io.grpc.channelz.v1.ChannelTraceEvent.Builder
-
High level description of the event.
- getDescription() - Method in class io.grpc.channelz.v1.ChannelTraceEvent
-
High level description of the event.
- getDescription() - Method in interface io.grpc.channelz.v1.ChannelTraceEventOrBuilder
-
High level description of the event.
- getDescription() - Method in interface io.grpc.MetricInstrument
-
Returns a description of the metric.
- getDescription() - Method in class io.grpc.PartialMetricInstrument
- getDescription() - Method in class io.grpc.Status
-
A description of this status for human consumption.
- getDescriptionBytes() - Method in class io.grpc.channelz.v1.ChannelTraceEvent.Builder
-
High level description of the event.
- getDescriptionBytes() - Method in class io.grpc.channelz.v1.ChannelTraceEvent
-
High level description of the event.
- getDescriptionBytes() - Method in interface io.grpc.channelz.v1.ChannelTraceEventOrBuilder
-
High level description of the event.
- getDescriptor() - Static method in class io.grpc.binarylog.v1.Address.Builder
- getDescriptor() - Static method in class io.grpc.binarylog.v1.Address
- getDescriptor() - Static method in enum io.grpc.binarylog.v1.Address.Type
- getDescriptor() - Static method in class io.grpc.binarylog.v1.BinaryLogProto
- getDescriptor() - Static method in class io.grpc.binarylog.v1.ClientHeader.Builder
- getDescriptor() - Static method in class io.grpc.binarylog.v1.ClientHeader
- getDescriptor() - Static method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
- getDescriptor() - Static method in enum io.grpc.binarylog.v1.GrpcLogEntry.EventType
- getDescriptor() - Static method in class io.grpc.binarylog.v1.GrpcLogEntry
- getDescriptor() - Static method in enum io.grpc.binarylog.v1.GrpcLogEntry.Logger
- getDescriptor() - Static method in class io.grpc.binarylog.v1.Message.Builder
- getDescriptor() - Static method in class io.grpc.binarylog.v1.Message
- getDescriptor() - Static method in class io.grpc.binarylog.v1.Metadata.Builder
- getDescriptor() - Static method in class io.grpc.binarylog.v1.Metadata
- getDescriptor() - Static method in class io.grpc.binarylog.v1.MetadataEntry.Builder
- getDescriptor() - Static method in class io.grpc.binarylog.v1.MetadataEntry
- getDescriptor() - Static method in class io.grpc.binarylog.v1.ServerHeader.Builder
- getDescriptor() - Static method in class io.grpc.binarylog.v1.ServerHeader
- getDescriptor() - Static method in class io.grpc.binarylog.v1.Trailer.Builder
- getDescriptor() - Static method in class io.grpc.binarylog.v1.Trailer
- getDescriptor() - Static method in class io.grpc.channelz.v1.Address.Builder
- getDescriptor() - Static method in class io.grpc.channelz.v1.Address
- getDescriptor() - Static method in class io.grpc.channelz.v1.Address.OtherAddress.Builder
- getDescriptor() - Static method in class io.grpc.channelz.v1.Address.OtherAddress
- getDescriptor() - Static method in class io.grpc.channelz.v1.Address.TcpIpAddress.Builder
- getDescriptor() - Static method in class io.grpc.channelz.v1.Address.TcpIpAddress
- getDescriptor() - Static method in class io.grpc.channelz.v1.Address.UdsAddress.Builder
- getDescriptor() - Static method in class io.grpc.channelz.v1.Address.UdsAddress
- getDescriptor() - Static method in class io.grpc.channelz.v1.Channel.Builder
- getDescriptor() - Static method in class io.grpc.channelz.v1.Channel
- getDescriptor() - Static method in class io.grpc.channelz.v1.ChannelConnectivityState.Builder
- getDescriptor() - Static method in class io.grpc.channelz.v1.ChannelConnectivityState
- getDescriptor() - Static method in enum io.grpc.channelz.v1.ChannelConnectivityState.State
- getDescriptor() - Static method in class io.grpc.channelz.v1.ChannelData.Builder
- getDescriptor() - Static method in class io.grpc.channelz.v1.ChannelData
- getDescriptor() - Static method in class io.grpc.channelz.v1.ChannelRef.Builder
- getDescriptor() - Static method in class io.grpc.channelz.v1.ChannelRef
- getDescriptor() - Static method in class io.grpc.channelz.v1.ChannelTrace.Builder
- getDescriptor() - Static method in class io.grpc.channelz.v1.ChannelTrace
- getDescriptor() - Static method in class io.grpc.channelz.v1.ChannelTraceEvent.Builder
- getDescriptor() - Static method in class io.grpc.channelz.v1.ChannelTraceEvent
- getDescriptor() - Static method in enum io.grpc.channelz.v1.ChannelTraceEvent.Severity
- getDescriptor() - Static method in class io.grpc.channelz.v1.ChannelzProto
- getDescriptor() - Static method in class io.grpc.channelz.v1.GetChannelRequest.Builder
- getDescriptor() - Static method in class io.grpc.channelz.v1.GetChannelRequest
- getDescriptor() - Static method in class io.grpc.channelz.v1.GetChannelResponse.Builder
- getDescriptor() - Static method in class io.grpc.channelz.v1.GetChannelResponse
- getDescriptor() - Static method in class io.grpc.channelz.v1.GetServerRequest.Builder
- getDescriptor() - Static method in class io.grpc.channelz.v1.GetServerRequest
- getDescriptor() - Static method in class io.grpc.channelz.v1.GetServerResponse.Builder
- getDescriptor() - Static method in class io.grpc.channelz.v1.GetServerResponse
- getDescriptor() - Static method in class io.grpc.channelz.v1.GetServerSocketsRequest.Builder
- getDescriptor() - Static method in class io.grpc.channelz.v1.GetServerSocketsRequest
- getDescriptor() - Static method in class io.grpc.channelz.v1.GetServerSocketsResponse.Builder
- getDescriptor() - Static method in class io.grpc.channelz.v1.GetServerSocketsResponse
- getDescriptor() - Static method in class io.grpc.channelz.v1.GetServersRequest.Builder
- getDescriptor() - Static method in class io.grpc.channelz.v1.GetServersRequest
- getDescriptor() - Static method in class io.grpc.channelz.v1.GetServersResponse.Builder
- getDescriptor() - Static method in class io.grpc.channelz.v1.GetServersResponse
- getDescriptor() - Static method in class io.grpc.channelz.v1.GetSocketRequest.Builder
- getDescriptor() - Static method in class io.grpc.channelz.v1.GetSocketRequest
- getDescriptor() - Static method in class io.grpc.channelz.v1.GetSocketResponse.Builder
- getDescriptor() - Static method in class io.grpc.channelz.v1.GetSocketResponse
- getDescriptor() - Static method in class io.grpc.channelz.v1.GetSubchannelRequest.Builder
- getDescriptor() - Static method in class io.grpc.channelz.v1.GetSubchannelRequest
- getDescriptor() - Static method in class io.grpc.channelz.v1.GetSubchannelResponse.Builder
- getDescriptor() - Static method in class io.grpc.channelz.v1.GetSubchannelResponse
- getDescriptor() - Static method in class io.grpc.channelz.v1.GetTopChannelsRequest.Builder
- getDescriptor() - Static method in class io.grpc.channelz.v1.GetTopChannelsRequest
- getDescriptor() - Static method in class io.grpc.channelz.v1.GetTopChannelsResponse.Builder
- getDescriptor() - Static method in class io.grpc.channelz.v1.GetTopChannelsResponse
- getDescriptor() - Static method in class io.grpc.channelz.v1.Security.Builder
- getDescriptor() - Static method in class io.grpc.channelz.v1.Security
- getDescriptor() - Static method in class io.grpc.channelz.v1.Security.OtherSecurity.Builder
- getDescriptor() - Static method in class io.grpc.channelz.v1.Security.OtherSecurity
- getDescriptor() - Static method in class io.grpc.channelz.v1.Security.Tls.Builder
- getDescriptor() - Static method in class io.grpc.channelz.v1.Security.Tls
- getDescriptor() - Static method in class io.grpc.channelz.v1.Server.Builder
- getDescriptor() - Static method in class io.grpc.channelz.v1.Server
- getDescriptor() - Static method in class io.grpc.channelz.v1.ServerData.Builder
- getDescriptor() - Static method in class io.grpc.channelz.v1.ServerData
- getDescriptor() - Static method in class io.grpc.channelz.v1.ServerRef.Builder
- getDescriptor() - Static method in class io.grpc.channelz.v1.ServerRef
- getDescriptor() - Static method in class io.grpc.channelz.v1.Socket.Builder
- getDescriptor() - Static method in class io.grpc.channelz.v1.Socket
- getDescriptor() - Static method in class io.grpc.channelz.v1.SocketData.Builder
- getDescriptor() - Static method in class io.grpc.channelz.v1.SocketData
- getDescriptor() - Static method in class io.grpc.channelz.v1.SocketOption.Builder
- getDescriptor() - Static method in class io.grpc.channelz.v1.SocketOption
- getDescriptor() - Static method in class io.grpc.channelz.v1.SocketOptionLinger.Builder
- getDescriptor() - Static method in class io.grpc.channelz.v1.SocketOptionLinger
- getDescriptor() - Static method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
- getDescriptor() - Static method in class io.grpc.channelz.v1.SocketOptionTcpInfo
- getDescriptor() - Static method in class io.grpc.channelz.v1.SocketOptionTimeout.Builder
- getDescriptor() - Static method in class io.grpc.channelz.v1.SocketOptionTimeout
- getDescriptor() - Static method in class io.grpc.channelz.v1.SocketRef.Builder
- getDescriptor() - Static method in class io.grpc.channelz.v1.SocketRef
- getDescriptor() - Static method in class io.grpc.channelz.v1.Subchannel.Builder
- getDescriptor() - Static method in class io.grpc.channelz.v1.Subchannel
- getDescriptor() - Static method in class io.grpc.channelz.v1.SubchannelRef.Builder
- getDescriptor() - Static method in class io.grpc.channelz.v1.SubchannelRef
- getDescriptor() - Static method in class io.grpc.health.v1.HealthCheckRequest.Builder
- getDescriptor() - Static method in class io.grpc.health.v1.HealthCheckRequest
- getDescriptor() - Static method in class io.grpc.health.v1.HealthCheckResponse.Builder
- getDescriptor() - Static method in class io.grpc.health.v1.HealthCheckResponse
- getDescriptor() - Static method in enum io.grpc.health.v1.HealthCheckResponse.ServingStatus
- getDescriptor() - Static method in class io.grpc.health.v1.HealthProto
- getDescriptor() - Static method in class io.grpc.lb.v1.ClientStats.Builder
- getDescriptor() - Static method in class io.grpc.lb.v1.ClientStats
- getDescriptor() - Static method in class io.grpc.lb.v1.ClientStatsPerToken.Builder
- getDescriptor() - Static method in class io.grpc.lb.v1.ClientStatsPerToken
- getDescriptor() - Static method in class io.grpc.lb.v1.FallbackResponse.Builder
- getDescriptor() - Static method in class io.grpc.lb.v1.FallbackResponse
- getDescriptor() - Static method in class io.grpc.lb.v1.InitialLoadBalanceRequest.Builder
- getDescriptor() - Static method in class io.grpc.lb.v1.InitialLoadBalanceRequest
- getDescriptor() - Static method in class io.grpc.lb.v1.InitialLoadBalanceResponse.Builder
- getDescriptor() - Static method in class io.grpc.lb.v1.InitialLoadBalanceResponse
- getDescriptor() - Static method in class io.grpc.lb.v1.LoadBalanceRequest.Builder
- getDescriptor() - Static method in class io.grpc.lb.v1.LoadBalanceRequest
- getDescriptor() - Static method in class io.grpc.lb.v1.LoadBalanceResponse.Builder
- getDescriptor() - Static method in class io.grpc.lb.v1.LoadBalanceResponse
- getDescriptor() - Static method in class io.grpc.lb.v1.LoadBalancerProto
- getDescriptor() - Static method in class io.grpc.lb.v1.Server.Builder
- getDescriptor() - Static method in class io.grpc.lb.v1.Server
- getDescriptor() - Static method in class io.grpc.lb.v1.ServerList.Builder
- getDescriptor() - Static method in class io.grpc.lb.v1.ServerList
- getDescriptor() - Static method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
- getDescriptor() - Static method in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys.Builder
- getDescriptor() - Static method in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys
- getDescriptor() - Static method in class io.grpc.lookup.v1.GrpcKeyBuilder
- getDescriptor() - Static method in class io.grpc.lookup.v1.GrpcKeyBuilder.Name.Builder
- getDescriptor() - Static method in class io.grpc.lookup.v1.GrpcKeyBuilder.Name
- getDescriptor() - Static method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
- getDescriptor() - Static method in class io.grpc.lookup.v1.HttpKeyBuilder
- getDescriptor() - Static method in class io.grpc.lookup.v1.NameMatcher.Builder
- getDescriptor() - Static method in class io.grpc.lookup.v1.NameMatcher
- getDescriptor() - Static method in class io.grpc.lookup.v1.RlsConfigProto
- getDescriptor() - Static method in class io.grpc.lookup.v1.RlsProto
- getDescriptor() - Static method in class io.grpc.lookup.v1.RouteLookupClusterSpecifier.Builder
- getDescriptor() - Static method in class io.grpc.lookup.v1.RouteLookupClusterSpecifier
- getDescriptor() - Static method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
- getDescriptor() - Static method in class io.grpc.lookup.v1.RouteLookupConfig
- getDescriptor() - Static method in class io.grpc.lookup.v1.RouteLookupRequest.Builder
- getDescriptor() - Static method in class io.grpc.lookup.v1.RouteLookupRequest
- getDescriptor() - Static method in enum io.grpc.lookup.v1.RouteLookupRequest.Reason
- getDescriptor() - Static method in class io.grpc.lookup.v1.RouteLookupResponse.Builder
- getDescriptor() - Static method in class io.grpc.lookup.v1.RouteLookupResponse
- getDescriptor() - Static method in class io.grpc.reflection.v1.ErrorResponse.Builder
- getDescriptor() - Static method in class io.grpc.reflection.v1.ErrorResponse
- getDescriptor() - Static method in class io.grpc.reflection.v1.ExtensionNumberResponse.Builder
- getDescriptor() - Static method in class io.grpc.reflection.v1.ExtensionNumberResponse
- getDescriptor() - Static method in class io.grpc.reflection.v1.ExtensionRequest.Builder
- getDescriptor() - Static method in class io.grpc.reflection.v1.ExtensionRequest
- getDescriptor() - Static method in class io.grpc.reflection.v1.FileDescriptorResponse.Builder
- getDescriptor() - Static method in class io.grpc.reflection.v1.FileDescriptorResponse
- getDescriptor() - Static method in class io.grpc.reflection.v1.ListServiceResponse.Builder
- getDescriptor() - Static method in class io.grpc.reflection.v1.ListServiceResponse
- getDescriptor() - Static method in class io.grpc.reflection.v1.ServerReflectionProto
- getDescriptor() - Static method in class io.grpc.reflection.v1.ServerReflectionRequest.Builder
- getDescriptor() - Static method in class io.grpc.reflection.v1.ServerReflectionRequest
- getDescriptor() - Static method in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
- getDescriptor() - Static method in class io.grpc.reflection.v1.ServerReflectionResponse
- getDescriptor() - Static method in class io.grpc.reflection.v1.ServiceResponse.Builder
- getDescriptor() - Static method in class io.grpc.reflection.v1.ServiceResponse
- getDescriptor() - Static method in class io.grpc.reflection.v1alpha.ErrorResponse.Builder
- getDescriptor() - Static method in class io.grpc.reflection.v1alpha.ErrorResponse
- getDescriptor() - Static method in class io.grpc.reflection.v1alpha.ExtensionNumberResponse.Builder
- getDescriptor() - Static method in class io.grpc.reflection.v1alpha.ExtensionNumberResponse
- getDescriptor() - Static method in class io.grpc.reflection.v1alpha.ExtensionRequest.Builder
- getDescriptor() - Static method in class io.grpc.reflection.v1alpha.ExtensionRequest
- getDescriptor() - Static method in class io.grpc.reflection.v1alpha.FileDescriptorResponse.Builder
- getDescriptor() - Static method in class io.grpc.reflection.v1alpha.FileDescriptorResponse
- getDescriptor() - Static method in class io.grpc.reflection.v1alpha.ListServiceResponse.Builder
- getDescriptor() - Static method in class io.grpc.reflection.v1alpha.ListServiceResponse
- getDescriptor() - Static method in class io.grpc.reflection.v1alpha.ServerReflectionProto
-
Deprecated.
- getDescriptor() - Static method in class io.grpc.reflection.v1alpha.ServerReflectionRequest.Builder
- getDescriptor() - Static method in class io.grpc.reflection.v1alpha.ServerReflectionRequest
- getDescriptor() - Static method in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
- getDescriptor() - Static method in class io.grpc.reflection.v1alpha.ServerReflectionResponse
- getDescriptor() - Static method in class io.grpc.reflection.v1alpha.ServiceResponse.Builder
- getDescriptor() - Static method in class io.grpc.reflection.v1alpha.ServiceResponse
- getDescriptorForType() - Method in class io.grpc.binarylog.v1.Address.Builder
- getDescriptorForType() - Method in enum io.grpc.binarylog.v1.Address.Type
- getDescriptorForType() - Method in class io.grpc.binarylog.v1.ClientHeader.Builder
- getDescriptorForType() - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
- getDescriptorForType() - Method in enum io.grpc.binarylog.v1.GrpcLogEntry.EventType
- getDescriptorForType() - Method in enum io.grpc.binarylog.v1.GrpcLogEntry.Logger
- getDescriptorForType() - Method in class io.grpc.binarylog.v1.Message.Builder
- getDescriptorForType() - Method in class io.grpc.binarylog.v1.Metadata.Builder
- getDescriptorForType() - Method in class io.grpc.binarylog.v1.MetadataEntry.Builder
- getDescriptorForType() - Method in class io.grpc.binarylog.v1.ServerHeader.Builder
- getDescriptorForType() - Method in class io.grpc.binarylog.v1.Trailer.Builder
- getDescriptorForType() - Method in class io.grpc.channelz.v1.Address.Builder
- getDescriptorForType() - Method in class io.grpc.channelz.v1.Address.OtherAddress.Builder
- getDescriptorForType() - Method in class io.grpc.channelz.v1.Address.TcpIpAddress.Builder
- getDescriptorForType() - Method in class io.grpc.channelz.v1.Address.UdsAddress.Builder
- getDescriptorForType() - Method in class io.grpc.channelz.v1.Channel.Builder
- getDescriptorForType() - Method in class io.grpc.channelz.v1.ChannelConnectivityState.Builder
- getDescriptorForType() - Method in enum io.grpc.channelz.v1.ChannelConnectivityState.State
- getDescriptorForType() - Method in class io.grpc.channelz.v1.ChannelData.Builder
- getDescriptorForType() - Method in class io.grpc.channelz.v1.ChannelRef.Builder
- getDescriptorForType() - Method in class io.grpc.channelz.v1.ChannelTrace.Builder
- getDescriptorForType() - Method in class io.grpc.channelz.v1.ChannelTraceEvent.Builder
- getDescriptorForType() - Method in enum io.grpc.channelz.v1.ChannelTraceEvent.Severity
- getDescriptorForType() - Method in class io.grpc.channelz.v1.GetChannelRequest.Builder
- getDescriptorForType() - Method in class io.grpc.channelz.v1.GetChannelResponse.Builder
- getDescriptorForType() - Method in class io.grpc.channelz.v1.GetServerRequest.Builder
- getDescriptorForType() - Method in class io.grpc.channelz.v1.GetServerResponse.Builder
- getDescriptorForType() - Method in class io.grpc.channelz.v1.GetServerSocketsRequest.Builder
- getDescriptorForType() - Method in class io.grpc.channelz.v1.GetServerSocketsResponse.Builder
- getDescriptorForType() - Method in class io.grpc.channelz.v1.GetServersRequest.Builder
- getDescriptorForType() - Method in class io.grpc.channelz.v1.GetServersResponse.Builder
- getDescriptorForType() - Method in class io.grpc.channelz.v1.GetSocketRequest.Builder
- getDescriptorForType() - Method in class io.grpc.channelz.v1.GetSocketResponse.Builder
- getDescriptorForType() - Method in class io.grpc.channelz.v1.GetSubchannelRequest.Builder
- getDescriptorForType() - Method in class io.grpc.channelz.v1.GetSubchannelResponse.Builder
- getDescriptorForType() - Method in class io.grpc.channelz.v1.GetTopChannelsRequest.Builder
- getDescriptorForType() - Method in class io.grpc.channelz.v1.GetTopChannelsResponse.Builder
- getDescriptorForType() - Method in class io.grpc.channelz.v1.Security.Builder
- getDescriptorForType() - Method in class io.grpc.channelz.v1.Security.OtherSecurity.Builder
- getDescriptorForType() - Method in class io.grpc.channelz.v1.Security.Tls.Builder
- getDescriptorForType() - Method in class io.grpc.channelz.v1.Server.Builder
- getDescriptorForType() - Method in class io.grpc.channelz.v1.ServerData.Builder
- getDescriptorForType() - Method in class io.grpc.channelz.v1.ServerRef.Builder
- getDescriptorForType() - Method in class io.grpc.channelz.v1.Socket.Builder
- getDescriptorForType() - Method in class io.grpc.channelz.v1.SocketData.Builder
- getDescriptorForType() - Method in class io.grpc.channelz.v1.SocketOption.Builder
- getDescriptorForType() - Method in class io.grpc.channelz.v1.SocketOptionLinger.Builder
- getDescriptorForType() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
- getDescriptorForType() - Method in class io.grpc.channelz.v1.SocketOptionTimeout.Builder
- getDescriptorForType() - Method in class io.grpc.channelz.v1.SocketRef.Builder
- getDescriptorForType() - Method in class io.grpc.channelz.v1.Subchannel.Builder
- getDescriptorForType() - Method in class io.grpc.channelz.v1.SubchannelRef.Builder
- getDescriptorForType() - Method in class io.grpc.health.v1.HealthCheckRequest.Builder
- getDescriptorForType() - Method in class io.grpc.health.v1.HealthCheckResponse.Builder
- getDescriptorForType() - Method in enum io.grpc.health.v1.HealthCheckResponse.ServingStatus
- getDescriptorForType() - Method in class io.grpc.lb.v1.ClientStats.Builder
- getDescriptorForType() - Method in class io.grpc.lb.v1.ClientStatsPerToken.Builder
- getDescriptorForType() - Method in class io.grpc.lb.v1.FallbackResponse.Builder
- getDescriptorForType() - Method in class io.grpc.lb.v1.InitialLoadBalanceRequest.Builder
- getDescriptorForType() - Method in class io.grpc.lb.v1.InitialLoadBalanceResponse.Builder
- getDescriptorForType() - Method in class io.grpc.lb.v1.LoadBalanceRequest.Builder
- getDescriptorForType() - Method in class io.grpc.lb.v1.LoadBalanceResponse.Builder
- getDescriptorForType() - Method in class io.grpc.lb.v1.Server.Builder
- getDescriptorForType() - Method in class io.grpc.lb.v1.ServerList.Builder
- getDescriptorForType() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
- getDescriptorForType() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys.Builder
- getDescriptorForType() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Name.Builder
- getDescriptorForType() - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
- getDescriptorForType() - Method in class io.grpc.lookup.v1.NameMatcher.Builder
- getDescriptorForType() - Method in class io.grpc.lookup.v1.RouteLookupClusterSpecifier.Builder
- getDescriptorForType() - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
- getDescriptorForType() - Method in class io.grpc.lookup.v1.RouteLookupRequest.Builder
- getDescriptorForType() - Method in enum io.grpc.lookup.v1.RouteLookupRequest.Reason
- getDescriptorForType() - Method in class io.grpc.lookup.v1.RouteLookupResponse.Builder
- getDescriptorForType() - Method in class io.grpc.reflection.v1.ErrorResponse.Builder
- getDescriptorForType() - Method in class io.grpc.reflection.v1.ExtensionNumberResponse.Builder
- getDescriptorForType() - Method in class io.grpc.reflection.v1.ExtensionRequest.Builder
- getDescriptorForType() - Method in class io.grpc.reflection.v1.FileDescriptorResponse.Builder
- getDescriptorForType() - Method in class io.grpc.reflection.v1.ListServiceResponse.Builder
- getDescriptorForType() - Method in class io.grpc.reflection.v1.ServerReflectionRequest.Builder
- getDescriptorForType() - Method in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
- getDescriptorForType() - Method in class io.grpc.reflection.v1.ServiceResponse.Builder
- getDescriptorForType() - Method in class io.grpc.reflection.v1alpha.ErrorResponse.Builder
- getDescriptorForType() - Method in class io.grpc.reflection.v1alpha.ExtensionNumberResponse.Builder
- getDescriptorForType() - Method in class io.grpc.reflection.v1alpha.ExtensionRequest.Builder
- getDescriptorForType() - Method in class io.grpc.reflection.v1alpha.FileDescriptorResponse.Builder
- getDescriptorForType() - Method in class io.grpc.reflection.v1alpha.ListServiceResponse.Builder
- getDescriptorForType() - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest.Builder
- getDescriptorForType() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
- getDescriptorForType() - Method in class io.grpc.reflection.v1alpha.ServiceResponse.Builder
- getDetails() - Method in class io.grpc.InternalLogId
- getDouble(CharSequence) - Method in class io.grpc.netty.AbstractHttp2Headers
- getDouble(CharSequence, double) - Method in class io.grpc.netty.AbstractHttp2Headers
- getDoubleAndRemove(CharSequence) - Method in class io.grpc.netty.AbstractHttp2Headers
- getDoubleAndRemove(CharSequence, double) - Method in class io.grpc.netty.AbstractHttp2Headers
- getDrop() - Method in class io.grpc.lb.v1.Server.Builder
-
Indicates whether this particular request should be dropped by the client.
- getDrop() - Method in class io.grpc.lb.v1.Server
-
Indicates whether this particular request should be dropped by the client.
- getDrop() - Method in interface io.grpc.lb.v1.ServerOrBuilder
-
Indicates whether this particular request should be dropped by the client.
- getDuration() - Method in class io.grpc.channelz.v1.SocketOptionLinger.Builder
-
duration maps to `struct linger.l_linger`
- getDuration() - Method in class io.grpc.channelz.v1.SocketOptionLinger
-
duration maps to `struct linger.l_linger`
- getDuration() - Method in interface io.grpc.channelz.v1.SocketOptionLingerOrBuilder
-
duration maps to `struct linger.l_linger`
- getDuration() - Method in class io.grpc.channelz.v1.SocketOptionTimeout.Builder
-
.google.protobuf.Duration duration = 1;
- getDuration() - Method in class io.grpc.channelz.v1.SocketOptionTimeout
-
.google.protobuf.Duration duration = 1;
- getDuration() - Method in interface io.grpc.channelz.v1.SocketOptionTimeoutOrBuilder
-
.google.protobuf.Duration duration = 1;
- getDurationBuilder() - Method in class io.grpc.channelz.v1.SocketOptionLinger.Builder
-
duration maps to `struct linger.l_linger`
- getDurationBuilder() - Method in class io.grpc.channelz.v1.SocketOptionTimeout.Builder
-
.google.protobuf.Duration duration = 1;
- getDurationFieldBuilder() - Method in class io.grpc.channelz.v1.SocketOptionLinger.Builder
-
duration maps to `struct linger.l_linger`
- getDurationFieldBuilder() - Method in class io.grpc.channelz.v1.SocketOptionTimeout.Builder
-
.google.protobuf.Duration duration = 1;
- getDurationOrBuilder() - Method in class io.grpc.channelz.v1.SocketOptionLinger.Builder
-
duration maps to `struct linger.l_linger`
- getDurationOrBuilder() - Method in class io.grpc.channelz.v1.SocketOptionLinger
-
duration maps to `struct linger.l_linger`
- getDurationOrBuilder() - Method in interface io.grpc.channelz.v1.SocketOptionLingerOrBuilder
-
duration maps to `struct linger.l_linger`
- getDurationOrBuilder() - Method in class io.grpc.channelz.v1.SocketOptionTimeout.Builder
-
.google.protobuf.Duration duration = 1;
- getDurationOrBuilder() - Method in class io.grpc.channelz.v1.SocketOptionTimeout
-
.google.protobuf.Duration duration = 1;
- getDurationOrBuilder() - Method in interface io.grpc.channelz.v1.SocketOptionTimeoutOrBuilder
-
.google.protobuf.Duration duration = 1;
- getEag() - Method in class io.grpc.util.MultiChildLoadBalancer.ChildLbState
- getEagAttributes() - Method in class io.grpc.internal.ClientTransportFactory.ClientTransportOptions
- getEagAttributes() - Method in class io.grpc.netty.GrpcHttp2ConnectionHandler
-
Get the attributes of the EquivalentAddressGroup used to create this transport.
- getEagAttributes() - Method in class io.grpc.netty.NettyClientHandler
- getEagAttributes() - Method in class io.grpc.netty.NettyServerHandler
- getEffectiveChildPolicy(String) - Method in class io.grpc.rls.LbPolicyConfiguration.ChildLoadBalancingPolicy
-
Creates a child load balancer config for given target from elected raw child policy.
- getEffectiveInterceptors(String) - Method in class io.grpc.internal.ManagedChannelImplBuilder
- getEffectiveLbProvider() - Method in class io.grpc.rls.LbPolicyConfiguration.ChildLoadBalancingPolicy
-
Returns the elected child
LoadBalancerProvider
. - getEnabledMetrics() - Method in interface io.grpc.MetricSink
-
Returns a set of names for the metrics that are currently enabled or disabled.
- getEnd() - Method in class io.grpc.channelz.v1.GetServerSocketsResponse.Builder
-
If set, indicates that the list of sockets is the final list.
- getEnd() - Method in class io.grpc.channelz.v1.GetServerSocketsResponse
-
If set, indicates that the list of sockets is the final list.
- getEnd() - Method in interface io.grpc.channelz.v1.GetServerSocketsResponseOrBuilder
-
If set, indicates that the list of sockets is the final list.
- getEnd() - Method in class io.grpc.channelz.v1.GetServersResponse.Builder
-
If set, indicates that the list of servers is the final list.
- getEnd() - Method in class io.grpc.channelz.v1.GetServersResponse
-
If set, indicates that the list of servers is the final list.
- getEnd() - Method in interface io.grpc.channelz.v1.GetServersResponseOrBuilder
-
If set, indicates that the list of servers is the final list.
- getEnd() - Method in class io.grpc.channelz.v1.GetTopChannelsResponse.Builder
-
If set, indicates that the list of channels is the final list.
- getEnd() - Method in class io.grpc.channelz.v1.GetTopChannelsResponse
-
If set, indicates that the list of channels is the final list.
- getEnd() - Method in interface io.grpc.channelz.v1.GetTopChannelsResponseOrBuilder
-
If set, indicates that the list of channels is the final list.
- getEntry(int) - Method in class io.grpc.binarylog.v1.Metadata.Builder
-
repeated .grpc.binarylog.v1.MetadataEntry entry = 1;
- getEntry(int) - Method in class io.grpc.binarylog.v1.Metadata
-
repeated .grpc.binarylog.v1.MetadataEntry entry = 1;
- getEntry(int) - Method in interface io.grpc.binarylog.v1.MetadataOrBuilder
-
repeated .grpc.binarylog.v1.MetadataEntry entry = 1;
- getEntryBuilder(int) - Method in class io.grpc.binarylog.v1.Metadata.Builder
-
repeated .grpc.binarylog.v1.MetadataEntry entry = 1;
- getEntryBuilderList() - Method in class io.grpc.binarylog.v1.Metadata.Builder
-
repeated .grpc.binarylog.v1.MetadataEntry entry = 1;
- getEntryCount() - Method in class io.grpc.binarylog.v1.Metadata.Builder
-
repeated .grpc.binarylog.v1.MetadataEntry entry = 1;
- getEntryCount() - Method in class io.grpc.binarylog.v1.Metadata
-
repeated .grpc.binarylog.v1.MetadataEntry entry = 1;
- getEntryCount() - Method in interface io.grpc.binarylog.v1.MetadataOrBuilder
-
repeated .grpc.binarylog.v1.MetadataEntry entry = 1;
- getEntryFieldBuilder() - Method in class io.grpc.binarylog.v1.Metadata.Builder
- getEntryList() - Method in class io.grpc.binarylog.v1.Metadata.Builder
-
repeated .grpc.binarylog.v1.MetadataEntry entry = 1;
- getEntryList() - Method in class io.grpc.binarylog.v1.Metadata
-
repeated .grpc.binarylog.v1.MetadataEntry entry = 1;
- getEntryList() - Method in interface io.grpc.binarylog.v1.MetadataOrBuilder
-
repeated .grpc.binarylog.v1.MetadataEntry entry = 1;
- getEntryOrBuilder(int) - Method in class io.grpc.binarylog.v1.Metadata.Builder
-
repeated .grpc.binarylog.v1.MetadataEntry entry = 1;
- getEntryOrBuilder(int) - Method in class io.grpc.binarylog.v1.Metadata
-
repeated .grpc.binarylog.v1.MetadataEntry entry = 1;
- getEntryOrBuilder(int) - Method in interface io.grpc.binarylog.v1.MetadataOrBuilder
-
repeated .grpc.binarylog.v1.MetadataEntry entry = 1;
- getEntryOrBuilderList() - Method in class io.grpc.binarylog.v1.Metadata.Builder
-
repeated .grpc.binarylog.v1.MetadataEntry entry = 1;
- getEntryOrBuilderList() - Method in class io.grpc.binarylog.v1.Metadata
-
repeated .grpc.binarylog.v1.MetadataEntry entry = 1;
- getEntryOrBuilderList() - Method in interface io.grpc.binarylog.v1.MetadataOrBuilder
-
repeated .grpc.binarylog.v1.MetadataEntry entry = 1;
- getEpollChannelOption(String) - Static method in class io.grpc.netty.Utils
- getEpollUnavailabilityCause() - Static method in class io.grpc.netty.Utils
- getEps() - Method in class io.grpc.services.MetricReport
- getError() - Method in class io.grpc.internal.FailingClientStream
- getError() - Method in class io.grpc.ManagedChannelProvider.NewChannelBuilderResult
- getError() - Method in class io.grpc.NameResolver.ConfigOrError
-
Returns error status if exists, otherwise null.
- getError() - Method in class io.grpc.ServerProvider.NewServerBuilderResult
- getErrorCode() - Method in class io.grpc.reflection.v1.ErrorResponse.Builder
-
This field uses the error codes defined in grpc::StatusCode.
- getErrorCode() - Method in class io.grpc.reflection.v1.ErrorResponse
-
This field uses the error codes defined in grpc::StatusCode.
- getErrorCode() - Method in interface io.grpc.reflection.v1.ErrorResponseOrBuilder
-
This field uses the error codes defined in grpc::StatusCode.
- getErrorCode() - Method in class io.grpc.reflection.v1alpha.ErrorResponse.Builder
-
This field uses the error codes defined in grpc::StatusCode.
- getErrorCode() - Method in class io.grpc.reflection.v1alpha.ErrorResponse
-
This field uses the error codes defined in grpc::StatusCode.
- getErrorCode() - Method in interface io.grpc.reflection.v1alpha.ErrorResponseOrBuilder
-
This field uses the error codes defined in grpc::StatusCode.
- getErrorMessage() - Method in class io.grpc.reflection.v1.ErrorResponse.Builder
-
string error_message = 2;
- getErrorMessage() - Method in class io.grpc.reflection.v1.ErrorResponse
-
string error_message = 2;
- getErrorMessage() - Method in interface io.grpc.reflection.v1.ErrorResponseOrBuilder
-
string error_message = 2;
- getErrorMessage() - Method in class io.grpc.reflection.v1alpha.ErrorResponse.Builder
-
string error_message = 2;
- getErrorMessage() - Method in class io.grpc.reflection.v1alpha.ErrorResponse
-
string error_message = 2;
- getErrorMessage() - Method in interface io.grpc.reflection.v1alpha.ErrorResponseOrBuilder
-
string error_message = 2;
- getErrorMessageBytes() - Method in class io.grpc.reflection.v1.ErrorResponse.Builder
-
string error_message = 2;
- getErrorMessageBytes() - Method in class io.grpc.reflection.v1.ErrorResponse
-
string error_message = 2;
- getErrorMessageBytes() - Method in interface io.grpc.reflection.v1.ErrorResponseOrBuilder
-
string error_message = 2;
- getErrorMessageBytes() - Method in class io.grpc.reflection.v1alpha.ErrorResponse.Builder
-
string error_message = 2;
- getErrorMessageBytes() - Method in class io.grpc.reflection.v1alpha.ErrorResponse
-
string error_message = 2;
- getErrorMessageBytes() - Method in interface io.grpc.reflection.v1alpha.ErrorResponseOrBuilder
-
string error_message = 2;
- getErrorResponse() - Method in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
-
This message is used when an error occurs.
- getErrorResponse() - Method in class io.grpc.reflection.v1.ServerReflectionResponse
-
This message is used when an error occurs.
- getErrorResponse() - Method in interface io.grpc.reflection.v1.ServerReflectionResponseOrBuilder
-
This message is used when an error occurs.
- getErrorResponse() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
-
This message is used when an error occurs.
- getErrorResponse() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse
-
This message is used when an error occurs.
- getErrorResponse() - Method in interface io.grpc.reflection.v1alpha.ServerReflectionResponseOrBuilder
-
This message is used when an error occurs.
- getErrorResponseBuilder() - Method in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
-
This message is used when an error occurs.
- getErrorResponseBuilder() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
-
This message is used when an error occurs.
- getErrorResponseFieldBuilder() - Method in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
-
This message is used when an error occurs.
- getErrorResponseFieldBuilder() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
-
This message is used when an error occurs.
- getErrorResponseOrBuilder() - Method in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
-
This message is used when an error occurs.
- getErrorResponseOrBuilder() - Method in class io.grpc.reflection.v1.ServerReflectionResponse
-
This message is used when an error occurs.
- getErrorResponseOrBuilder() - Method in interface io.grpc.reflection.v1.ServerReflectionResponseOrBuilder
-
This message is used when an error occurs.
- getErrorResponseOrBuilder() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
-
This message is used when an error occurs.
- getErrorResponseOrBuilder() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse
-
This message is used when an error occurs.
- getErrorResponseOrBuilder() - Method in interface io.grpc.reflection.v1alpha.ServerReflectionResponseOrBuilder
-
This message is used when an error occurs.
- getEvents(int) - Method in class io.grpc.channelz.v1.ChannelTrace.Builder
-
List of events that have occurred on this channel.
- getEvents(int) - Method in class io.grpc.channelz.v1.ChannelTrace
-
List of events that have occurred on this channel.
- getEvents(int) - Method in interface io.grpc.channelz.v1.ChannelTraceOrBuilder
-
List of events that have occurred on this channel.
- getEventsBuilder(int) - Method in class io.grpc.channelz.v1.ChannelTrace.Builder
-
List of events that have occurred on this channel.
- getEventsBuilderList() - Method in class io.grpc.channelz.v1.ChannelTrace.Builder
-
List of events that have occurred on this channel.
- getEventsCount() - Method in class io.grpc.channelz.v1.ChannelTrace.Builder
-
List of events that have occurred on this channel.
- getEventsCount() - Method in class io.grpc.channelz.v1.ChannelTrace
-
List of events that have occurred on this channel.
- getEventsCount() - Method in interface io.grpc.channelz.v1.ChannelTraceOrBuilder
-
List of events that have occurred on this channel.
- getEventsFieldBuilder() - Method in class io.grpc.channelz.v1.ChannelTrace.Builder
- getEventsList() - Method in class io.grpc.channelz.v1.ChannelTrace.Builder
-
List of events that have occurred on this channel.
- getEventsList() - Method in class io.grpc.channelz.v1.ChannelTrace
-
List of events that have occurred on this channel.
- getEventsList() - Method in interface io.grpc.channelz.v1.ChannelTraceOrBuilder
-
List of events that have occurred on this channel.
- getEventsOrBuilder(int) - Method in class io.grpc.channelz.v1.ChannelTrace.Builder
-
List of events that have occurred on this channel.
- getEventsOrBuilder(int) - Method in class io.grpc.channelz.v1.ChannelTrace
-
List of events that have occurred on this channel.
- getEventsOrBuilder(int) - Method in interface io.grpc.channelz.v1.ChannelTraceOrBuilder
-
List of events that have occurred on this channel.
- getEventsOrBuilderList() - Method in class io.grpc.channelz.v1.ChannelTrace.Builder
-
List of events that have occurred on this channel.
- getEventsOrBuilderList() - Method in class io.grpc.channelz.v1.ChannelTrace
-
List of events that have occurred on this channel.
- getEventsOrBuilderList() - Method in interface io.grpc.channelz.v1.ChannelTraceOrBuilder
-
List of events that have occurred on this channel.
- getExecutor() - Method in class io.grpc.CallOptions
-
Returns the executor override to use for this specific call, or
null
if there is no override. - getExecutor() - Method in class io.grpc.internal.ManagedChannelImpl.ExecutorHolder
- getExecutor(ServerCall<ReqT, RespT>, Metadata) - Method in interface io.grpc.ServerCallExecutorSupplier
-
Returns an executor to handle the server call.
- getExecutorPool() - Method in class io.grpc.internal.ServerImplBuilder
-
Returns the internal ExecutorPool for offloading tasks.
- getExtensionNumber() - Method in class io.grpc.reflection.v1.ExtensionRequest.Builder
-
int32 extension_number = 2;
- getExtensionNumber() - Method in class io.grpc.reflection.v1.ExtensionRequest
-
int32 extension_number = 2;
- getExtensionNumber() - Method in interface io.grpc.reflection.v1.ExtensionRequestOrBuilder
-
int32 extension_number = 2;
- getExtensionNumber() - Method in class io.grpc.reflection.v1alpha.ExtensionRequest.Builder
-
int32 extension_number = 2;
- getExtensionNumber() - Method in class io.grpc.reflection.v1alpha.ExtensionRequest
-
int32 extension_number = 2;
- getExtensionNumber() - Method in interface io.grpc.reflection.v1alpha.ExtensionRequestOrBuilder
-
int32 extension_number = 2;
- getExtensionNumber(int) - Method in class io.grpc.reflection.v1.ExtensionNumberResponse.Builder
-
repeated int32 extension_number = 2;
- getExtensionNumber(int) - Method in class io.grpc.reflection.v1.ExtensionNumberResponse
-
repeated int32 extension_number = 2;
- getExtensionNumber(int) - Method in interface io.grpc.reflection.v1.ExtensionNumberResponseOrBuilder
-
repeated int32 extension_number = 2;
- getExtensionNumber(int) - Method in class io.grpc.reflection.v1alpha.ExtensionNumberResponse.Builder
-
repeated int32 extension_number = 2;
- getExtensionNumber(int) - Method in class io.grpc.reflection.v1alpha.ExtensionNumberResponse
-
repeated int32 extension_number = 2;
- getExtensionNumber(int) - Method in interface io.grpc.reflection.v1alpha.ExtensionNumberResponseOrBuilder
-
repeated int32 extension_number = 2;
- getExtensionNumberCount() - Method in class io.grpc.reflection.v1.ExtensionNumberResponse.Builder
-
repeated int32 extension_number = 2;
- getExtensionNumberCount() - Method in class io.grpc.reflection.v1.ExtensionNumberResponse
-
repeated int32 extension_number = 2;
- getExtensionNumberCount() - Method in interface io.grpc.reflection.v1.ExtensionNumberResponseOrBuilder
-
repeated int32 extension_number = 2;
- getExtensionNumberCount() - Method in class io.grpc.reflection.v1alpha.ExtensionNumberResponse.Builder
-
repeated int32 extension_number = 2;
- getExtensionNumberCount() - Method in class io.grpc.reflection.v1alpha.ExtensionNumberResponse
-
repeated int32 extension_number = 2;
- getExtensionNumberCount() - Method in interface io.grpc.reflection.v1alpha.ExtensionNumberResponseOrBuilder
-
repeated int32 extension_number = 2;
- getExtensionNumberList() - Method in class io.grpc.reflection.v1.ExtensionNumberResponse.Builder
-
repeated int32 extension_number = 2;
- getExtensionNumberList() - Method in class io.grpc.reflection.v1.ExtensionNumberResponse
-
repeated int32 extension_number = 2;
- getExtensionNumberList() - Method in interface io.grpc.reflection.v1.ExtensionNumberResponseOrBuilder
-
repeated int32 extension_number = 2;
- getExtensionNumberList() - Method in class io.grpc.reflection.v1alpha.ExtensionNumberResponse.Builder
-
repeated int32 extension_number = 2;
- getExtensionNumberList() - Method in class io.grpc.reflection.v1alpha.ExtensionNumberResponse
-
repeated int32 extension_number = 2;
- getExtensionNumberList() - Method in interface io.grpc.reflection.v1alpha.ExtensionNumberResponseOrBuilder
-
repeated int32 extension_number = 2;
- getExtensionNumbersOfType(String) - Method in class io.grpc.protobuf.services.ProtoReflectionServiceV1.FileDescriptorIndex
- getExtensionNumbersOfType(String) - Method in class io.grpc.protobuf.services.ProtoReflectionServiceV1.ServerReflectionIndex
- getExtraKeys() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
-
.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys extra_keys = 3;
- getExtraKeys() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder
-
.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys extra_keys = 3;
- getExtraKeys() - Method in interface io.grpc.lookup.v1.GrpcKeyBuilderOrBuilder
-
.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys extra_keys = 3;
- getExtraKeysBuilder() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
-
.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys extra_keys = 3;
- getExtraKeysFieldBuilder() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
-
.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys extra_keys = 3;
- getExtraKeysOrBuilder() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
-
.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys extra_keys = 3;
- getExtraKeysOrBuilder() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder
-
.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys extra_keys = 3;
- getExtraKeysOrBuilder() - Method in interface io.grpc.lookup.v1.GrpcKeyBuilderOrBuilder
-
.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys extra_keys = 3;
- getFallbackResponse() - Method in class io.grpc.lb.v1.LoadBalanceResponse.Builder
-
If this field is set, then the client should eagerly enter fallback mode (even if there are existing, healthy connections to backends).
- getFallbackResponse() - Method in class io.grpc.lb.v1.LoadBalanceResponse
-
If this field is set, then the client should eagerly enter fallback mode (even if there are existing, healthy connections to backends).
- getFallbackResponse() - Method in interface io.grpc.lb.v1.LoadBalanceResponseOrBuilder
-
If this field is set, then the client should eagerly enter fallback mode (even if there are existing, healthy connections to backends).
- getFallbackResponseBuilder() - Method in class io.grpc.lb.v1.LoadBalanceResponse.Builder
-
If this field is set, then the client should eagerly enter fallback mode (even if there are existing, healthy connections to backends).
- getFallbackResponseFieldBuilder() - Method in class io.grpc.lb.v1.LoadBalanceResponse.Builder
-
If this field is set, then the client should eagerly enter fallback mode (even if there are existing, healthy connections to backends).
- getFallbackResponseOrBuilder() - Method in class io.grpc.lb.v1.LoadBalanceResponse.Builder
-
If this field is set, then the client should eagerly enter fallback mode (even if there are existing, healthy connections to backends).
- getFallbackResponseOrBuilder() - Method in class io.grpc.lb.v1.LoadBalanceResponse
-
If this field is set, then the client should eagerly enter fallback mode (even if there are existing, healthy connections to backends).
- getFallbackResponseOrBuilder() - Method in interface io.grpc.lb.v1.LoadBalanceResponseOrBuilder
-
If this field is set, then the client should eagerly enter fallback mode (even if there are existing, healthy connections to backends).
- getFallbackTimeoutMs() - Method in class io.grpc.grpclb.GrpclbConfig
- getFileByExtension(ServerReflectionRequest) - Method in class io.grpc.protobuf.services.ProtoReflectionServiceV1.ProtoReflectionStreamObserver
- getFileByFilename() - Method in class io.grpc.reflection.v1.ServerReflectionRequest.Builder
-
Find a proto file by the file name.
- getFileByFilename() - Method in class io.grpc.reflection.v1.ServerReflectionRequest
-
Find a proto file by the file name.
- getFileByFilename() - Method in interface io.grpc.reflection.v1.ServerReflectionRequestOrBuilder
-
Find a proto file by the file name.
- getFileByFilename() - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest.Builder
-
Find a proto file by the file name.
- getFileByFilename() - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest
-
Find a proto file by the file name.
- getFileByFilename() - Method in interface io.grpc.reflection.v1alpha.ServerReflectionRequestOrBuilder
-
Find a proto file by the file name.
- getFileByFilenameBytes() - Method in class io.grpc.reflection.v1.ServerReflectionRequest.Builder
-
Find a proto file by the file name.
- getFileByFilenameBytes() - Method in class io.grpc.reflection.v1.ServerReflectionRequest
-
Find a proto file by the file name.
- getFileByFilenameBytes() - Method in interface io.grpc.reflection.v1.ServerReflectionRequestOrBuilder
-
Find a proto file by the file name.
- getFileByFilenameBytes() - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest.Builder
-
Find a proto file by the file name.
- getFileByFilenameBytes() - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest
-
Find a proto file by the file name.
- getFileByFilenameBytes() - Method in interface io.grpc.reflection.v1alpha.ServerReflectionRequestOrBuilder
-
Find a proto file by the file name.
- getFileByName(ServerReflectionRequest) - Method in class io.grpc.protobuf.services.ProtoReflectionServiceV1.ProtoReflectionStreamObserver
- getFileContainingExtension() - Method in class io.grpc.reflection.v1.ServerReflectionRequest.Builder
-
Find the proto file which defines an extension extending the given message type with the given field number.
- getFileContainingExtension() - Method in class io.grpc.reflection.v1.ServerReflectionRequest
-
Find the proto file which defines an extension extending the given message type with the given field number.
- getFileContainingExtension() - Method in interface io.grpc.reflection.v1.ServerReflectionRequestOrBuilder
-
Find the proto file which defines an extension extending the given message type with the given field number.
- getFileContainingExtension() - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest.Builder
-
Find the proto file which defines an extension extending the given message type with the given field number.
- getFileContainingExtension() - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest
-
Find the proto file which defines an extension extending the given message type with the given field number.
- getFileContainingExtension() - Method in interface io.grpc.reflection.v1alpha.ServerReflectionRequestOrBuilder
-
Find the proto file which defines an extension extending the given message type with the given field number.
- getFileContainingExtensionBuilder() - Method in class io.grpc.reflection.v1.ServerReflectionRequest.Builder
-
Find the proto file which defines an extension extending the given message type with the given field number.
- getFileContainingExtensionBuilder() - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest.Builder
-
Find the proto file which defines an extension extending the given message type with the given field number.
- getFileContainingExtensionFieldBuilder() - Method in class io.grpc.reflection.v1.ServerReflectionRequest.Builder
-
Find the proto file which defines an extension extending the given message type with the given field number.
- getFileContainingExtensionFieldBuilder() - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest.Builder
-
Find the proto file which defines an extension extending the given message type with the given field number.
- getFileContainingExtensionOrBuilder() - Method in class io.grpc.reflection.v1.ServerReflectionRequest.Builder
-
Find the proto file which defines an extension extending the given message type with the given field number.
- getFileContainingExtensionOrBuilder() - Method in class io.grpc.reflection.v1.ServerReflectionRequest
-
Find the proto file which defines an extension extending the given message type with the given field number.
- getFileContainingExtensionOrBuilder() - Method in interface io.grpc.reflection.v1.ServerReflectionRequestOrBuilder
-
Find the proto file which defines an extension extending the given message type with the given field number.
- getFileContainingExtensionOrBuilder() - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest.Builder
-
Find the proto file which defines an extension extending the given message type with the given field number.
- getFileContainingExtensionOrBuilder() - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest
-
Find the proto file which defines an extension extending the given message type with the given field number.
- getFileContainingExtensionOrBuilder() - Method in interface io.grpc.reflection.v1alpha.ServerReflectionRequestOrBuilder
-
Find the proto file which defines an extension extending the given message type with the given field number.
- getFileContainingSymbol() - Method in class io.grpc.reflection.v1.ServerReflectionRequest.Builder
-
Find the proto file that declares the given fully-qualified symbol name.
- getFileContainingSymbol() - Method in class io.grpc.reflection.v1.ServerReflectionRequest
-
Find the proto file that declares the given fully-qualified symbol name.
- getFileContainingSymbol() - Method in interface io.grpc.reflection.v1.ServerReflectionRequestOrBuilder
-
Find the proto file that declares the given fully-qualified symbol name.
- getFileContainingSymbol() - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest.Builder
-
Find the proto file that declares the given fully-qualified symbol name.
- getFileContainingSymbol() - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest
-
Find the proto file that declares the given fully-qualified symbol name.
- getFileContainingSymbol() - Method in interface io.grpc.reflection.v1alpha.ServerReflectionRequestOrBuilder
-
Find the proto file that declares the given fully-qualified symbol name.
- getFileContainingSymbol(ServerReflectionRequest) - Method in class io.grpc.protobuf.services.ProtoReflectionServiceV1.ProtoReflectionStreamObserver
- getFileContainingSymbolBytes() - Method in class io.grpc.reflection.v1.ServerReflectionRequest.Builder
-
Find the proto file that declares the given fully-qualified symbol name.
- getFileContainingSymbolBytes() - Method in class io.grpc.reflection.v1.ServerReflectionRequest
-
Find the proto file that declares the given fully-qualified symbol name.
- getFileContainingSymbolBytes() - Method in interface io.grpc.reflection.v1.ServerReflectionRequestOrBuilder
-
Find the proto file that declares the given fully-qualified symbol name.
- getFileContainingSymbolBytes() - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest.Builder
-
Find the proto file that declares the given fully-qualified symbol name.
- getFileContainingSymbolBytes() - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest
-
Find the proto file that declares the given fully-qualified symbol name.
- getFileContainingSymbolBytes() - Method in interface io.grpc.reflection.v1alpha.ServerReflectionRequestOrBuilder
-
Find the proto file that declares the given fully-qualified symbol name.
- getFileDescriptor() - Method in class io.grpc.channelz.v1.ChannelzGrpc.ChannelzBaseDescriptorSupplier
- getFileDescriptor() - Method in class io.grpc.health.v1.HealthGrpc.HealthBaseDescriptorSupplier
- getFileDescriptor() - Method in class io.grpc.lb.v1.LoadBalancerGrpc.LoadBalancerBaseDescriptorSupplier
- getFileDescriptor() - Method in class io.grpc.lookup.v1.RouteLookupServiceGrpc.RouteLookupServiceBaseDescriptorSupplier
- getFileDescriptor() - Method in interface io.grpc.protobuf.ProtoFileDescriptorSupplier
-
Returns file descriptor to the underlying proto file.
- getFileDescriptor() - Method in class io.grpc.reflection.v1.ServerReflectionGrpc.ServerReflectionBaseDescriptorSupplier
- getFileDescriptor() - Method in class io.grpc.reflection.v1alpha.ServerReflectionGrpc.ServerReflectionBaseDescriptorSupplier
- getFileDescriptorByExtensionAndNumber(String, int) - Method in class io.grpc.protobuf.services.ProtoReflectionServiceV1.FileDescriptorIndex
- getFileDescriptorByExtensionAndNumber(String, int) - Method in class io.grpc.protobuf.services.ProtoReflectionServiceV1.ServerReflectionIndex
- getFileDescriptorByName(String) - Method in class io.grpc.protobuf.services.ProtoReflectionServiceV1.FileDescriptorIndex
- getFileDescriptorByName(String) - Method in class io.grpc.protobuf.services.ProtoReflectionServiceV1.ServerReflectionIndex
- getFileDescriptorBySymbol(String) - Method in class io.grpc.protobuf.services.ProtoReflectionServiceV1.FileDescriptorIndex
- getFileDescriptorBySymbol(String) - Method in class io.grpc.protobuf.services.ProtoReflectionServiceV1.ServerReflectionIndex
- getFileDescriptorProto(int) - Method in class io.grpc.reflection.v1.FileDescriptorResponse.Builder
-
Serialized FileDescriptorProto messages.
- getFileDescriptorProto(int) - Method in class io.grpc.reflection.v1.FileDescriptorResponse
-
Serialized FileDescriptorProto messages.
- getFileDescriptorProto(int) - Method in interface io.grpc.reflection.v1.FileDescriptorResponseOrBuilder
-
Serialized FileDescriptorProto messages.
- getFileDescriptorProto(int) - Method in class io.grpc.reflection.v1alpha.FileDescriptorResponse.Builder
-
Serialized FileDescriptorProto messages.
- getFileDescriptorProto(int) - Method in class io.grpc.reflection.v1alpha.FileDescriptorResponse
-
Serialized FileDescriptorProto messages.
- getFileDescriptorProto(int) - Method in interface io.grpc.reflection.v1alpha.FileDescriptorResponseOrBuilder
-
Serialized FileDescriptorProto messages.
- getFileDescriptorProtoCount() - Method in class io.grpc.reflection.v1.FileDescriptorResponse.Builder
-
Serialized FileDescriptorProto messages.
- getFileDescriptorProtoCount() - Method in class io.grpc.reflection.v1.FileDescriptorResponse
-
Serialized FileDescriptorProto messages.
- getFileDescriptorProtoCount() - Method in interface io.grpc.reflection.v1.FileDescriptorResponseOrBuilder
-
Serialized FileDescriptorProto messages.
- getFileDescriptorProtoCount() - Method in class io.grpc.reflection.v1alpha.FileDescriptorResponse.Builder
-
Serialized FileDescriptorProto messages.
- getFileDescriptorProtoCount() - Method in class io.grpc.reflection.v1alpha.FileDescriptorResponse
-
Serialized FileDescriptorProto messages.
- getFileDescriptorProtoCount() - Method in interface io.grpc.reflection.v1alpha.FileDescriptorResponseOrBuilder
-
Serialized FileDescriptorProto messages.
- getFileDescriptorProtoList() - Method in class io.grpc.reflection.v1.FileDescriptorResponse.Builder
-
Serialized FileDescriptorProto messages.
- getFileDescriptorProtoList() - Method in class io.grpc.reflection.v1.FileDescriptorResponse
-
Serialized FileDescriptorProto messages.
- getFileDescriptorProtoList() - Method in interface io.grpc.reflection.v1.FileDescriptorResponseOrBuilder
-
Serialized FileDescriptorProto messages.
- getFileDescriptorProtoList() - Method in class io.grpc.reflection.v1alpha.FileDescriptorResponse.Builder
-
Serialized FileDescriptorProto messages.
- getFileDescriptorProtoList() - Method in class io.grpc.reflection.v1alpha.FileDescriptorResponse
-
Serialized FileDescriptorProto messages.
- getFileDescriptorProtoList() - Method in interface io.grpc.reflection.v1alpha.FileDescriptorResponseOrBuilder
-
Serialized FileDescriptorProto messages.
- getFileDescriptorResponse() - Method in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
-
This message is used to answer file_by_filename, file_containing_symbol, file_containing_extension requests with transitive dependencies.
- getFileDescriptorResponse() - Method in class io.grpc.reflection.v1.ServerReflectionResponse
-
This message is used to answer file_by_filename, file_containing_symbol, file_containing_extension requests with transitive dependencies.
- getFileDescriptorResponse() - Method in interface io.grpc.reflection.v1.ServerReflectionResponseOrBuilder
-
This message is used to answer file_by_filename, file_containing_symbol, file_containing_extension requests with transitive dependencies.
- getFileDescriptorResponse() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
-
This message is used to answer file_by_filename, file_containing_symbol, file_containing_extension requests with transitive dependencies.
- getFileDescriptorResponse() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse
-
This message is used to answer file_by_filename, file_containing_symbol, file_containing_extension requests with transitive dependencies.
- getFileDescriptorResponse() - Method in interface io.grpc.reflection.v1alpha.ServerReflectionResponseOrBuilder
-
This message is used to answer file_by_filename, file_containing_symbol, file_containing_extension requests with transitive dependencies.
- getFileDescriptorResponseBuilder() - Method in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
-
This message is used to answer file_by_filename, file_containing_symbol, file_containing_extension requests with transitive dependencies.
- getFileDescriptorResponseBuilder() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
-
This message is used to answer file_by_filename, file_containing_symbol, file_containing_extension requests with transitive dependencies.
- getFileDescriptorResponseFieldBuilder() - Method in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
-
This message is used to answer file_by_filename, file_containing_symbol, file_containing_extension requests with transitive dependencies.
- getFileDescriptorResponseFieldBuilder() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
-
This message is used to answer file_by_filename, file_containing_symbol, file_containing_extension requests with transitive dependencies.
- getFileDescriptorResponseOrBuilder() - Method in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
-
This message is used to answer file_by_filename, file_containing_symbol, file_containing_extension requests with transitive dependencies.
- getFileDescriptorResponseOrBuilder() - Method in class io.grpc.reflection.v1.ServerReflectionResponse
-
This message is used to answer file_by_filename, file_containing_symbol, file_containing_extension requests with transitive dependencies.
- getFileDescriptorResponseOrBuilder() - Method in interface io.grpc.reflection.v1.ServerReflectionResponseOrBuilder
-
This message is used to answer file_by_filename, file_containing_symbol, file_containing_extension requests with transitive dependencies.
- getFileDescriptorResponseOrBuilder() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
-
This message is used to answer file_by_filename, file_containing_symbol, file_containing_extension requests with transitive dependencies.
- getFileDescriptorResponseOrBuilder() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse
-
This message is used to answer file_by_filename, file_containing_symbol, file_containing_extension requests with transitive dependencies.
- getFileDescriptorResponseOrBuilder() - Method in interface io.grpc.reflection.v1alpha.ServerReflectionResponseOrBuilder
-
This message is used to answer file_by_filename, file_containing_symbol, file_containing_extension requests with transitive dependencies.
- getFilename() - Method in class io.grpc.channelz.v1.Address.UdsAddress.Builder
-
string filename = 1;
- getFilename() - Method in class io.grpc.channelz.v1.Address.UdsAddress
-
string filename = 1;
- getFilename() - Method in interface io.grpc.channelz.v1.Address.UdsAddressOrBuilder
-
string filename = 1;
- getFilenameBytes() - Method in class io.grpc.channelz.v1.Address.UdsAddress.Builder
-
string filename = 1;
- getFilenameBytes() - Method in class io.grpc.channelz.v1.Address.UdsAddress
-
string filename = 1;
- getFilenameBytes() - Method in interface io.grpc.channelz.v1.Address.UdsAddressOrBuilder
-
string filename = 1;
- getFlag(String, boolean) - Static method in class io.grpc.internal.GrpcUtil
- getFloat(CharSequence) - Method in class io.grpc.netty.AbstractHttp2Headers
- getFloat(CharSequence, float) - Method in class io.grpc.netty.AbstractHttp2Headers
- getFloatAndRemove(CharSequence) - Method in class io.grpc.netty.AbstractHttp2Headers
- getFloatAndRemove(CharSequence, float) - Method in class io.grpc.netty.AbstractHttp2Headers
- GetFramer(Metadata, StatsTraceContext) - Constructor for class io.grpc.internal.AbstractClientStream.GetFramer
- getFullMethodName() - Method in class io.grpc.MethodDescriptor
-
The fully qualified name of the method.
- getFuture(ListenableFuture<T>) - Static method in class io.grpc.protobuf.services.ChannelzProtoUtil
- getGetChannelMethod - Static variable in class io.grpc.channelz.v1.ChannelzGrpc
- getGetChannelMethod() - Static method in class io.grpc.channelz.v1.ChannelzGrpc
- getGetServerMethod - Static variable in class io.grpc.channelz.v1.ChannelzGrpc
- getGetServerMethod() - Static method in class io.grpc.channelz.v1.ChannelzGrpc
- getGetServersMethod - Static variable in class io.grpc.channelz.v1.ChannelzGrpc
- getGetServersMethod() - Static method in class io.grpc.channelz.v1.ChannelzGrpc
- getGetServerSocketsMethod - Static variable in class io.grpc.channelz.v1.ChannelzGrpc
- getGetServerSocketsMethod() - Static method in class io.grpc.channelz.v1.ChannelzGrpc
- getGetSocketMethod - Static variable in class io.grpc.channelz.v1.ChannelzGrpc
- getGetSocketMethod() - Static method in class io.grpc.channelz.v1.ChannelzGrpc
- getGetSubchannelMethod - Static variable in class io.grpc.channelz.v1.ChannelzGrpc
- getGetSubchannelMethod() - Static method in class io.grpc.channelz.v1.ChannelzGrpc
- getGetTopChannelsMethod - Static variable in class io.grpc.channelz.v1.ChannelzGrpc
- getGetTopChannelsMethod() - Static method in class io.grpc.channelz.v1.ChannelzGrpc
- getGoAwayDebugString() - Method in class io.grpc.netty.GracefulServerCloseCommand
- getGraceTime() - Method in class io.grpc.netty.GracefulServerCloseCommand
-
Has no meaning if
getGraceTimeUnit() == null
. - getGraceTimeUnit() - Method in class io.grpc.netty.GracefulServerCloseCommand
- getGroupIndex() - Method in class io.grpc.internal.PickFirstLeafLoadBalancer
- getGroups() - Method in class io.grpc.internal.InternalSubchannel.Index
- getGrpcBuildVersion() - Static method in class io.grpc.internal.GrpcUtil
-
Returns the build version of gRPC.
- getGrpcKeybuilders(int) - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
Unordered specifications for constructing keys for gRPC requests.
- getGrpcKeybuilders(int) - Method in class io.grpc.lookup.v1.RouteLookupConfig
-
Unordered specifications for constructing keys for gRPC requests.
- getGrpcKeybuilders(int) - Method in interface io.grpc.lookup.v1.RouteLookupConfigOrBuilder
-
Unordered specifications for constructing keys for gRPC requests.
- getGrpcKeybuildersBuilder(int) - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
Unordered specifications for constructing keys for gRPC requests.
- getGrpcKeybuildersBuilderList() - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
Unordered specifications for constructing keys for gRPC requests.
- getGrpcKeybuildersCount() - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
Unordered specifications for constructing keys for gRPC requests.
- getGrpcKeybuildersCount() - Method in class io.grpc.lookup.v1.RouteLookupConfig
-
Unordered specifications for constructing keys for gRPC requests.
- getGrpcKeybuildersCount() - Method in interface io.grpc.lookup.v1.RouteLookupConfigOrBuilder
-
Unordered specifications for constructing keys for gRPC requests.
- getGrpcKeybuildersFieldBuilder() - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
- getGrpcKeybuildersList() - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
Unordered specifications for constructing keys for gRPC requests.
- getGrpcKeybuildersList() - Method in class io.grpc.lookup.v1.RouteLookupConfig
-
Unordered specifications for constructing keys for gRPC requests.
- getGrpcKeybuildersList() - Method in interface io.grpc.lookup.v1.RouteLookupConfigOrBuilder
-
Unordered specifications for constructing keys for gRPC requests.
- getGrpcKeybuildersOrBuilder(int) - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
Unordered specifications for constructing keys for gRPC requests.
- getGrpcKeybuildersOrBuilder(int) - Method in class io.grpc.lookup.v1.RouteLookupConfig
-
Unordered specifications for constructing keys for gRPC requests.
- getGrpcKeybuildersOrBuilder(int) - Method in interface io.grpc.lookup.v1.RouteLookupConfigOrBuilder
-
Unordered specifications for constructing keys for gRPC requests.
- getGrpcKeybuildersOrBuilderList() - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
Unordered specifications for constructing keys for gRPC requests.
- getGrpcKeybuildersOrBuilderList() - Method in class io.grpc.lookup.v1.RouteLookupConfig
-
Unordered specifications for constructing keys for gRPC requests.
- getGrpcKeybuildersOrBuilderList() - Method in interface io.grpc.lookup.v1.RouteLookupConfigOrBuilder
-
Unordered specifications for constructing keys for gRPC requests.
- getGrpclbState() - Method in class io.grpc.grpclb.GrpclbLoadBalancer
- getGrpcUserAgent(String, String) - Static method in class io.grpc.internal.GrpcUtil
-
Gets the User-Agent string for the gRPC transport.
- getHardCodedClasses() - Static method in class io.grpc.LoadBalancerRegistry
- getHardCodedClasses() - Static method in class io.grpc.ManagedChannelRegistry
- getHardCodedClasses() - Static method in class io.grpc.NameResolverRegistry
- getHardCodedClasses() - Static method in class io.grpc.ServerRegistry
- getHeaderData - Variable in class io.grpc.rls.AutoValue_RlsProtoData_RouteLookupResponse
- getHeaderData() - Method in class io.grpc.lookup.v1.RouteLookupResponse.Builder
-
Optional header value to pass along to AFE in the X-Google-RLS-Data header.
- getHeaderData() - Method in class io.grpc.lookup.v1.RouteLookupResponse
-
Optional header value to pass along to AFE in the X-Google-RLS-Data header.
- getHeaderData() - Method in interface io.grpc.lookup.v1.RouteLookupResponseOrBuilder
-
Optional header value to pass along to AFE in the X-Google-RLS-Data header.
- getHeaderData() - Method in class io.grpc.rls.AutoValue_RlsProtoData_RouteLookupResponse
- getHeaderData() - Method in class io.grpc.rls.CachingRlsLbClient.CachedRouteLookupResponse
- getHeaderData() - Method in class io.grpc.rls.CachingRlsLbClient.DataCacheEntry
- getHeaderData() - Method in class io.grpc.rls.RlsProtoData.RouteLookupResponse
-
Returns optional header data to pass along to AFE in the X-Google-RLS-Data header.
- getHeaderDataBytes() - Method in class io.grpc.lookup.v1.RouteLookupResponse.Builder
-
Optional header value to pass along to AFE in the X-Google-RLS-Data header.
- getHeaderDataBytes() - Method in class io.grpc.lookup.v1.RouteLookupResponse
-
Optional header value to pass along to AFE in the X-Google-RLS-Data header.
- getHeaderDataBytes() - Method in interface io.grpc.lookup.v1.RouteLookupResponseOrBuilder
-
Optional header value to pass along to AFE in the X-Google-RLS-Data header.
- getHeaders() - Method in class io.grpc.internal.PickSubchannelArgsImpl
- getHeaders() - Method in class io.grpc.LoadBalancer.PickSubchannelArgs
-
Headers of the call.
- getHeaders(int) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
-
Extract keys from all listed headers.
- getHeaders(int) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder
-
Extract keys from all listed headers.
- getHeaders(int) - Method in interface io.grpc.lookup.v1.GrpcKeyBuilderOrBuilder
-
Extract keys from all listed headers.
- getHeaders(int) - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
-
List of headers to try to match.
- getHeaders(int) - Method in class io.grpc.lookup.v1.HttpKeyBuilder
-
List of headers to try to match.
- getHeaders(int) - Method in interface io.grpc.lookup.v1.HttpKeyBuilderOrBuilder
-
List of headers to try to match.
- getHeaders(HttpServletRequest) - Static method in class io.grpc.servlet.jakarta.ServletAdapter
- getHeaders(HttpServletRequest) - Static method in class io.grpc.servlet.ServletAdapter
- getHeadersBuilder(int) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
-
Extract keys from all listed headers.
- getHeadersBuilder(int) - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
-
List of headers to try to match.
- getHeadersBuilderList() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
-
Extract keys from all listed headers.
- getHeadersBuilderList() - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
-
List of headers to try to match.
- getHeadersCount() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
-
Extract keys from all listed headers.
- getHeadersCount() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder
-
Extract keys from all listed headers.
- getHeadersCount() - Method in interface io.grpc.lookup.v1.GrpcKeyBuilderOrBuilder
-
Extract keys from all listed headers.
- getHeadersCount() - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
-
List of headers to try to match.
- getHeadersCount() - Method in class io.grpc.lookup.v1.HttpKeyBuilder
-
List of headers to try to match.
- getHeadersCount() - Method in interface io.grpc.lookup.v1.HttpKeyBuilderOrBuilder
-
List of headers to try to match.
- getHeadersFieldBuilder() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
- getHeadersFieldBuilder() - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
- getHeadersList() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
-
Extract keys from all listed headers.
- getHeadersList() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder
-
Extract keys from all listed headers.
- getHeadersList() - Method in interface io.grpc.lookup.v1.GrpcKeyBuilderOrBuilder
-
Extract keys from all listed headers.
- getHeadersList() - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
-
List of headers to try to match.
- getHeadersList() - Method in class io.grpc.lookup.v1.HttpKeyBuilder
-
List of headers to try to match.
- getHeadersList() - Method in interface io.grpc.lookup.v1.HttpKeyBuilderOrBuilder
-
List of headers to try to match.
- getHeadersOrBuilder(int) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
-
Extract keys from all listed headers.
- getHeadersOrBuilder(int) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder
-
Extract keys from all listed headers.
- getHeadersOrBuilder(int) - Method in interface io.grpc.lookup.v1.GrpcKeyBuilderOrBuilder
-
Extract keys from all listed headers.
- getHeadersOrBuilder(int) - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
-
List of headers to try to match.
- getHeadersOrBuilder(int) - Method in class io.grpc.lookup.v1.HttpKeyBuilder
-
List of headers to try to match.
- getHeadersOrBuilder(int) - Method in interface io.grpc.lookup.v1.HttpKeyBuilderOrBuilder
-
List of headers to try to match.
- getHeadersOrBuilderList() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
-
Extract keys from all listed headers.
- getHeadersOrBuilderList() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder
-
Extract keys from all listed headers.
- getHeadersOrBuilderList() - Method in interface io.grpc.lookup.v1.GrpcKeyBuilderOrBuilder
-
Extract keys from all listed headers.
- getHeadersOrBuilderList() - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
-
List of headers to try to match.
- getHeadersOrBuilderList() - Method in class io.grpc.lookup.v1.HttpKeyBuilder
-
List of headers to try to match.
- getHeadersOrBuilderList() - Method in interface io.grpc.lookup.v1.HttpKeyBuilderOrBuilder
-
List of headers to try to match.
- getHealthCheckedService(Map<String, ?>) - Static method in class io.grpc.internal.ServiceConfigUtil
-
Fetches the health-checked service config from service config.
- getHealthCheckedServiceName(Map<String, ?>) - Static method in class io.grpc.internal.ServiceConfigUtil
-
Fetches the health-checked service name from health-checked service config.
- getHealthCheckingConfig() - Method in class io.grpc.internal.ManagedChannelServiceConfig
- getHealthService() - Method in class io.grpc.protobuf.services.HealthStatusManager
-
Gets the health check service created in the constructor.
- getHealthService() - Method in class io.grpc.services.HealthStatusManager
-
Deprecated.Gets the health check service created in the constructor.
- getHealthState() - Method in class io.grpc.internal.PickFirstLeafLoadBalancer.SubchannelData
- getHedgingDelayNanosFromHedgingPolicy(Map<String, ?>) - Static method in class io.grpc.internal.ServiceConfigUtil
- getHedgingPolicyFromMethodConfig(Map<String, ?>) - Static method in class io.grpc.internal.ServiceConfigUtil
- getHelper() - Method in class io.grpc.rls.LbPolicyConfiguration.ChildPolicyWrapper
- getHelper() - Method in class io.grpc.util.MultiChildLoadBalancer
- getHost() - Method in class io.grpc.grpclb.GrpclbNameResolver
- getHost() - Method in class io.grpc.internal.DnsNameResolver
- getHost() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys.Builder
-
string host = 1;
- getHost() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys
-
string host = 1;
- getHost() - Method in interface io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeysOrBuilder
-
string host = 1;
- getHost() - Method in class io.grpc.reflection.v1.ServerReflectionRequest.Builder
-
string host = 1;
- getHost() - Method in class io.grpc.reflection.v1.ServerReflectionRequest
-
string host = 1;
- getHost() - Method in interface io.grpc.reflection.v1.ServerReflectionRequestOrBuilder
-
string host = 1;
- getHost() - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest.Builder
-
string host = 1;
- getHost() - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest
-
string host = 1;
- getHost() - Method in interface io.grpc.reflection.v1alpha.ServerReflectionRequestOrBuilder
-
string host = 1;
- getHostBytes() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys.Builder
-
string host = 1;
- getHostBytes() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys
-
string host = 1;
- getHostBytes() - Method in interface io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeysOrBuilder
-
string host = 1;
- getHostBytes() - Method in class io.grpc.reflection.v1.ServerReflectionRequest.Builder
-
string host = 1;
- getHostBytes() - Method in class io.grpc.reflection.v1.ServerReflectionRequest
-
string host = 1;
- getHostBytes() - Method in interface io.grpc.reflection.v1.ServerReflectionRequestOrBuilder
-
string host = 1;
- getHostBytes() - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest.Builder
-
string host = 1;
- getHostBytes() - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest
-
string host = 1;
- getHostBytes() - Method in interface io.grpc.reflection.v1alpha.ServerReflectionRequestOrBuilder
-
string host = 1;
- getHostnamesFromChoice(Map<String, ?>) - Static method in class io.grpc.internal.DnsNameResolver
- getHostPatterns(int) - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
-
host_pattern is an ordered list of host template patterns for the desired value.
- getHostPatterns(int) - Method in class io.grpc.lookup.v1.HttpKeyBuilder
-
host_pattern is an ordered list of host template patterns for the desired value.
- getHostPatterns(int) - Method in interface io.grpc.lookup.v1.HttpKeyBuilderOrBuilder
-
host_pattern is an ordered list of host template patterns for the desired value.
- getHostPatternsBytes(int) - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
-
host_pattern is an ordered list of host template patterns for the desired value.
- getHostPatternsBytes(int) - Method in class io.grpc.lookup.v1.HttpKeyBuilder
-
host_pattern is an ordered list of host template patterns for the desired value.
- getHostPatternsBytes(int) - Method in interface io.grpc.lookup.v1.HttpKeyBuilderOrBuilder
-
host_pattern is an ordered list of host template patterns for the desired value.
- getHostPatternsCount() - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
-
host_pattern is an ordered list of host template patterns for the desired value.
- getHostPatternsCount() - Method in class io.grpc.lookup.v1.HttpKeyBuilder
-
host_pattern is an ordered list of host template patterns for the desired value.
- getHostPatternsCount() - Method in interface io.grpc.lookup.v1.HttpKeyBuilderOrBuilder
-
host_pattern is an ordered list of host template patterns for the desired value.
- getHostPatternsList() - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
-
host_pattern is an ordered list of host template patterns for the desired value.
- getHostPatternsList() - Method in class io.grpc.lookup.v1.HttpKeyBuilder
-
host_pattern is an ordered list of host template patterns for the desired value.
- getHostPatternsList() - Method in interface io.grpc.lookup.v1.HttpKeyBuilderOrBuilder
-
host_pattern is an ordered list of host template patterns for the desired value.
- getHttpConnectProxiedSocketAddress() - Method in class io.grpc.internal.ClientTransportFactory.ClientTransportOptions
- getHttpKeybuilders(int) - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
Ordered specifications for constructing keys for HTTP requests.
- getHttpKeybuilders(int) - Method in class io.grpc.lookup.v1.RouteLookupConfig
-
Ordered specifications for constructing keys for HTTP requests.
- getHttpKeybuilders(int) - Method in interface io.grpc.lookup.v1.RouteLookupConfigOrBuilder
-
Ordered specifications for constructing keys for HTTP requests.
- getHttpKeybuildersBuilder(int) - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
Ordered specifications for constructing keys for HTTP requests.
- getHttpKeybuildersBuilderList() - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
Ordered specifications for constructing keys for HTTP requests.
- getHttpKeybuildersCount() - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
Ordered specifications for constructing keys for HTTP requests.
- getHttpKeybuildersCount() - Method in class io.grpc.lookup.v1.RouteLookupConfig
-
Ordered specifications for constructing keys for HTTP requests.
- getHttpKeybuildersCount() - Method in interface io.grpc.lookup.v1.RouteLookupConfigOrBuilder
-
Ordered specifications for constructing keys for HTTP requests.
- getHttpKeybuildersFieldBuilder() - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
- getHttpKeybuildersList() - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
Ordered specifications for constructing keys for HTTP requests.
- getHttpKeybuildersList() - Method in class io.grpc.lookup.v1.RouteLookupConfig
-
Ordered specifications for constructing keys for HTTP requests.
- getHttpKeybuildersList() - Method in interface io.grpc.lookup.v1.RouteLookupConfigOrBuilder
-
Ordered specifications for constructing keys for HTTP requests.
- getHttpKeybuildersOrBuilder(int) - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
Ordered specifications for constructing keys for HTTP requests.
- getHttpKeybuildersOrBuilder(int) - Method in class io.grpc.lookup.v1.RouteLookupConfig
-
Ordered specifications for constructing keys for HTTP requests.
- getHttpKeybuildersOrBuilder(int) - Method in interface io.grpc.lookup.v1.RouteLookupConfigOrBuilder
-
Ordered specifications for constructing keys for HTTP requests.
- getHttpKeybuildersOrBuilderList() - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
Ordered specifications for constructing keys for HTTP requests.
- getHttpKeybuildersOrBuilderList() - Method in class io.grpc.lookup.v1.RouteLookupConfig
-
Ordered specifications for constructing keys for HTTP requests.
- getHttpKeybuildersOrBuilderList() - Method in interface io.grpc.lookup.v1.RouteLookupConfigOrBuilder
-
Ordered specifications for constructing keys for HTTP requests.
- 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.
- getImplementationVersion() - Method in class io.grpc.internal.GrpcUtil.GrpcBuildVersion
- getIndex() - Method in interface io.grpc.MetricInstrument
-
Returns the unique index of this metric instrument.
- getIndex() - Method in class io.grpc.PartialMetricInstrument
- getInitialBackoffNanosFromRetryPolicy(Map<String, ?>) - Static method in class io.grpc.internal.ServiceConfigUtil
- getInitialRequest() - Method in class io.grpc.lb.v1.LoadBalanceRequest.Builder
-
This message should be sent on the first request to the load balancer.
- getInitialRequest() - Method in class io.grpc.lb.v1.LoadBalanceRequest
-
This message should be sent on the first request to the load balancer.
- getInitialRequest() - Method in interface io.grpc.lb.v1.LoadBalanceRequestOrBuilder
-
This message should be sent on the first request to the load balancer.
- getInitialRequestBuilder() - Method in class io.grpc.lb.v1.LoadBalanceRequest.Builder
-
This message should be sent on the first request to the load balancer.
- getInitialRequestFieldBuilder() - Method in class io.grpc.lb.v1.LoadBalanceRequest.Builder
-
This message should be sent on the first request to the load balancer.
- getInitialRequestOrBuilder() - Method in class io.grpc.lb.v1.LoadBalanceRequest.Builder
-
This message should be sent on the first request to the load balancer.
- getInitialRequestOrBuilder() - Method in class io.grpc.lb.v1.LoadBalanceRequest
-
This message should be sent on the first request to the load balancer.
- getInitialRequestOrBuilder() - Method in interface io.grpc.lb.v1.LoadBalanceRequestOrBuilder
-
This message should be sent on the first request to the load balancer.
- getInitialResponse() - Method in class io.grpc.lb.v1.LoadBalanceResponse.Builder
-
This message should be sent on the first response to the client.
- getInitialResponse() - Method in class io.grpc.lb.v1.LoadBalanceResponse
-
This message should be sent on the first response to the client.
- getInitialResponse() - Method in interface io.grpc.lb.v1.LoadBalanceResponseOrBuilder
-
This message should be sent on the first response to the client.
- getInitialResponseBuilder() - Method in class io.grpc.lb.v1.LoadBalanceResponse.Builder
-
This message should be sent on the first response to the client.
- getInitialResponseFieldBuilder() - Method in class io.grpc.lb.v1.LoadBalanceResponse.Builder
-
This message should be sent on the first response to the client.
- getInitialResponseOrBuilder() - Method in class io.grpc.lb.v1.LoadBalanceResponse.Builder
-
This message should be sent on the first response to the client.
- getInitialResponseOrBuilder() - Method in class io.grpc.lb.v1.LoadBalanceResponse
-
This message should be sent on the first response to the client.
- getInitialResponseOrBuilder() - Method in interface io.grpc.lb.v1.LoadBalanceResponseOrBuilder
-
This message should be sent on the first response to the client.
- getInstrumentedInternalSubchannel() - Method in class io.grpc.internal.AbstractSubchannel
-
Returns the InternalSubchannel as an
Instrumented<T>
for the sole purpose of channelz unit tests. - getInstrumentedInternalSubchannel() - Method in class io.grpc.internal.ManagedChannelImpl.SubchannelImpl
- getInt(CharSequence) - Method in class io.grpc.netty.AbstractHttp2Headers
- getInt(CharSequence, int) - Method in class io.grpc.netty.AbstractHttp2Headers
- getIntAndRemove(CharSequence) - Method in class io.grpc.netty.AbstractHttp2Headers
- getIntAndRemove(CharSequence, int) - Method in class io.grpc.netty.AbstractHttp2Headers
- getInterceptor() - Method in class io.grpc.InternalConfigSelector.Result
-
Returns an interceptor that will be applies to calls.
- getInternal(SharedResourceHolder.Resource<T>) - Method in class io.grpc.internal.SharedResourceHolder
-
Visible to unit tests.
- getInternalSubchannel() - Method in class io.grpc.internal.ManagedChannelImpl.SubchannelImpl
- getInternalSubchannel() - Method in class io.grpc.internal.OobChannel
- getInternalSubchannel() - Method in class io.grpc.LoadBalancer.Subchannel
-
(Internal use only) returns an object that represents the underlying subchannel that is used by the Channel for sending RPCs when this
LoadBalancer.Subchannel
is picked. - getInternalSubchannel() - Method in class io.grpc.util.ForwardingSubchannel
- getInterval() - Method in class io.grpc.rls.AdaptiveThrottler.TimeBasedAccumulator
-
Returns the interval used by this statistic.
- getIpAddress() - Method in class io.grpc.channelz.v1.Address.TcpIpAddress.Builder
-
Either the IPv4 or IPv6 address in bytes.
- getIpAddress() - Method in class io.grpc.channelz.v1.Address.TcpIpAddress
-
Either the IPv4 or IPv6 address in bytes.
- getIpAddress() - Method in interface io.grpc.channelz.v1.Address.TcpIpAddressOrBuilder
-
Either the IPv4 or IPv6 address in bytes.
- getIpAddress() - Method in class io.grpc.lb.v1.Server.Builder
-
A resolved address for the server, serialized in network-byte-order.
- getIpAddress() - Method in class io.grpc.lb.v1.Server
-
A resolved address for the server, serialized in network-byte-order.
- getIpAddress() - Method in interface io.grpc.lb.v1.ServerOrBuilder
-
A resolved address for the server, serialized in network-byte-order.
- getIpPort() - Method in class io.grpc.binarylog.v1.Address.Builder
-
only for TYPE_IPV4 and TYPE_IPV6
- getIpPort() - Method in class io.grpc.binarylog.v1.Address
-
only for TYPE_IPV4 and TYPE_IPV6
- getIpPort() - Method in interface io.grpc.binarylog.v1.AddressOrBuilder
-
only for TYPE_IPV4 and TYPE_IPV6
- getJava9AlpnUnavailabilityCause() - Static method in class io.grpc.netty.JettyTlsUtil
- getJettyAlpnUnavailabilityCause() - Static method in class io.grpc.netty.JettyTlsUtil
- getJettyNpnUnavailabilityCause() - Static method in class io.grpc.netty.JettyTlsUtil
- getKeepAliveManagerForTest() - Method in class io.grpc.netty.NettyServerHandler
- getKeepAlivesSent() - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The number of keep alives sent.
- getKeepAlivesSent() - Method in class io.grpc.channelz.v1.SocketData
-
The number of keep alives sent.
- getKeepAlivesSent() - Method in interface io.grpc.channelz.v1.SocketDataOrBuilder
-
The number of keep alives sent.
- getKey() - Method in class io.grpc.binarylog.v1.MetadataEntry.Builder
-
string key = 1;
- getKey() - Method in class io.grpc.binarylog.v1.MetadataEntry
-
string key = 1;
- getKey() - Method in interface io.grpc.binarylog.v1.MetadataEntryOrBuilder
-
string key = 1;
- getKey() - Method in class io.grpc.lookup.v1.NameMatcher.Builder
-
The name that will be used in the RLS key_map to refer to this value.
- getKey() - Method in class io.grpc.lookup.v1.NameMatcher
-
The name that will be used in the RLS key_map to refer to this value.
- getKey() - Method in interface io.grpc.lookup.v1.NameMatcherOrBuilder
-
The name that will be used in the RLS key_map to refer to this value.
- getKey() - Method in class io.grpc.netty.GrpcHttp2OutboundHeaders.Itr
- getKey() - Method in class io.grpc.util.MultiChildLoadBalancer.ChildLbState
- getKeyBytes() - Method in class io.grpc.binarylog.v1.MetadataEntry.Builder
-
string key = 1;
- getKeyBytes() - Method in class io.grpc.binarylog.v1.MetadataEntry
-
string key = 1;
- getKeyBytes() - Method in interface io.grpc.binarylog.v1.MetadataEntryOrBuilder
-
string key = 1;
- getKeyBytes() - Method in class io.grpc.lookup.v1.NameMatcher.Builder
-
The name that will be used in the RLS key_map to refer to this value.
- getKeyBytes() - Method in class io.grpc.lookup.v1.NameMatcher
-
The name that will be used in the RLS key_map to refer to this value.
- getKeyBytes() - Method in interface io.grpc.lookup.v1.NameMatcherOrBuilder
-
The name that will be used in the RLS key_map to refer to this value.
- getKeyManagers() - Method in class io.grpc.TlsChannelCredentials
-
Returns the key manager list which provides the client's identity.
- getKeyManagers() - Method in class io.grpc.TlsServerCredentials
-
Returns the key manager list which provides the server's identity.
- getKeyMap() - Method in class io.grpc.lookup.v1.RouteLookupRequest.Builder
-
Deprecated.
- getKeyMap() - Method in class io.grpc.lookup.v1.RouteLookupRequest
-
Deprecated.
- getKeyMap() - Method in interface io.grpc.lookup.v1.RouteLookupRequestOrBuilder
-
Deprecated.
- getKeyMapCount() - Method in class io.grpc.lookup.v1.RouteLookupRequest.Builder
- getKeyMapCount() - Method in class io.grpc.lookup.v1.RouteLookupRequest
- getKeyMapCount() - Method in interface io.grpc.lookup.v1.RouteLookupRequestOrBuilder
-
Map of key values extracted via key builders for the gRPC or HTTP request.
- getKeyMapMap() - Method in class io.grpc.lookup.v1.RouteLookupRequest.Builder
-
Map of key values extracted via key builders for the gRPC or HTTP request.
- getKeyMapMap() - Method in class io.grpc.lookup.v1.RouteLookupRequest
-
Map of key values extracted via key builders for the gRPC or HTTP request.
- getKeyMapMap() - Method in interface io.grpc.lookup.v1.RouteLookupRequestOrBuilder
-
Map of key values extracted via key builders for the gRPC or HTTP request.
- getKeyMapOrDefault(String, String) - Method in class io.grpc.lookup.v1.RouteLookupRequest.Builder
-
Map of key values extracted via key builders for the gRPC or HTTP request.
- getKeyMapOrDefault(String, String) - Method in class io.grpc.lookup.v1.RouteLookupRequest
-
Map of key values extracted via key builders for the gRPC or HTTP request.
- getKeyMapOrDefault(String, String) - Method in interface io.grpc.lookup.v1.RouteLookupRequestOrBuilder
-
Map of key values extracted via key builders for the gRPC or HTTP request.
- getKeyMapOrThrow(String) - Method in class io.grpc.lookup.v1.RouteLookupRequest.Builder
-
Map of key values extracted via key builders for the gRPC or HTTP request.
- getKeyMapOrThrow(String) - Method in class io.grpc.lookup.v1.RouteLookupRequest
-
Map of key values extracted via key builders for the gRPC or HTTP request.
- getKeyMapOrThrow(String) - Method in interface io.grpc.lookup.v1.RouteLookupRequestOrBuilder
-
Map of key values extracted via key builders for the gRPC or HTTP request.
- getKnownLength(InputStream) - Method in class io.grpc.internal.MessageFramer
- getKnownMessageEncodings() - Method in class io.grpc.DecompressorRegistry
-
Provides a list of all message encodings that have decompressors available.
- getLastCallStartedTimestamp() - Method in class io.grpc.channelz.v1.ChannelData.Builder
-
The last time a call was started on the channel.
- getLastCallStartedTimestamp() - Method in class io.grpc.channelz.v1.ChannelData
-
The last time a call was started on the channel.
- getLastCallStartedTimestamp() - Method in interface io.grpc.channelz.v1.ChannelDataOrBuilder
-
The last time a call was started on the channel.
- getLastCallStartedTimestamp() - Method in class io.grpc.channelz.v1.ServerData.Builder
-
The last time a call was started on the server.
- getLastCallStartedTimestamp() - Method in class io.grpc.channelz.v1.ServerData
-
The last time a call was started on the server.
- getLastCallStartedTimestamp() - Method in interface io.grpc.channelz.v1.ServerDataOrBuilder
-
The last time a call was started on the server.
- getLastCallStartedTimestampBuilder() - Method in class io.grpc.channelz.v1.ChannelData.Builder
-
The last time a call was started on the channel.
- getLastCallStartedTimestampBuilder() - Method in class io.grpc.channelz.v1.ServerData.Builder
-
The last time a call was started on the server.
- getLastCallStartedTimestampFieldBuilder() - Method in class io.grpc.channelz.v1.ChannelData.Builder
-
The last time a call was started on the channel.
- getLastCallStartedTimestampFieldBuilder() - Method in class io.grpc.channelz.v1.ServerData.Builder
-
The last time a call was started on the server.
- getLastCallStartedTimestampOrBuilder() - Method in class io.grpc.channelz.v1.ChannelData.Builder
-
The last time a call was started on the channel.
- getLastCallStartedTimestampOrBuilder() - Method in class io.grpc.channelz.v1.ChannelData
-
The last time a call was started on the channel.
- getLastCallStartedTimestampOrBuilder() - Method in interface io.grpc.channelz.v1.ChannelDataOrBuilder
-
The last time a call was started on the channel.
- getLastCallStartedTimestampOrBuilder() - Method in class io.grpc.channelz.v1.ServerData.Builder
-
The last time a call was started on the server.
- getLastCallStartedTimestampOrBuilder() - Method in class io.grpc.channelz.v1.ServerData
-
The last time a call was started on the server.
- getLastCallStartedTimestampOrBuilder() - Method in interface io.grpc.channelz.v1.ServerDataOrBuilder
-
The last time a call was started on the server.
- getLastLocalStreamCreatedTimestamp() - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The last time a stream was created by this endpoint.
- getLastLocalStreamCreatedTimestamp() - Method in class io.grpc.channelz.v1.SocketData
-
The last time a stream was created by this endpoint.
- getLastLocalStreamCreatedTimestamp() - Method in interface io.grpc.channelz.v1.SocketDataOrBuilder
-
The last time a stream was created by this endpoint.
- getLastLocalStreamCreatedTimestampBuilder() - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The last time a stream was created by this endpoint.
- getLastLocalStreamCreatedTimestampFieldBuilder() - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The last time a stream was created by this endpoint.
- getLastLocalStreamCreatedTimestampOrBuilder() - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The last time a stream was created by this endpoint.
- getLastLocalStreamCreatedTimestampOrBuilder() - Method in class io.grpc.channelz.v1.SocketData
-
The last time a stream was created by this endpoint.
- getLastLocalStreamCreatedTimestampOrBuilder() - Method in interface io.grpc.channelz.v1.SocketDataOrBuilder
-
The last time a stream was created by this endpoint.
- getLastMessageReceivedTimestamp() - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The last time a message was received by this endpoint.
- getLastMessageReceivedTimestamp() - Method in class io.grpc.channelz.v1.SocketData
-
The last time a message was received by this endpoint.
- getLastMessageReceivedTimestamp() - Method in interface io.grpc.channelz.v1.SocketDataOrBuilder
-
The last time a message was received by this endpoint.
- getLastMessageReceivedTimestampBuilder() - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The last time a message was received by this endpoint.
- getLastMessageReceivedTimestampFieldBuilder() - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The last time a message was received by this endpoint.
- getLastMessageReceivedTimestampOrBuilder() - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The last time a message was received by this endpoint.
- getLastMessageReceivedTimestampOrBuilder() - Method in class io.grpc.channelz.v1.SocketData
-
The last time a message was received by this endpoint.
- getLastMessageReceivedTimestampOrBuilder() - Method in interface io.grpc.channelz.v1.SocketDataOrBuilder
-
The last time a message was received by this endpoint.
- getLastMessageSentTimestamp() - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The last time a message was sent by this endpoint.
- getLastMessageSentTimestamp() - Method in class io.grpc.channelz.v1.SocketData
-
The last time a message was sent by this endpoint.
- getLastMessageSentTimestamp() - Method in interface io.grpc.channelz.v1.SocketDataOrBuilder
-
The last time a message was sent by this endpoint.
- getLastMessageSentTimestampBuilder() - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The last time a message was sent by this endpoint.
- getLastMessageSentTimestampFieldBuilder() - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The last time a message was sent by this endpoint.
- getLastMessageSentTimestampOrBuilder() - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The last time a message was sent by this endpoint.
- getLastMessageSentTimestampOrBuilder() - Method in class io.grpc.channelz.v1.SocketData
-
The last time a message was sent by this endpoint.
- getLastMessageSentTimestampOrBuilder() - Method in interface io.grpc.channelz.v1.SocketDataOrBuilder
-
The last time a message was sent by this endpoint.
- getLastRemoteStreamCreatedTimestamp() - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The last time a stream was created by the remote endpoint.
- getLastRemoteStreamCreatedTimestamp() - Method in class io.grpc.channelz.v1.SocketData
-
The last time a stream was created by the remote endpoint.
- getLastRemoteStreamCreatedTimestamp() - Method in interface io.grpc.channelz.v1.SocketDataOrBuilder
-
The last time a stream was created by the remote endpoint.
- getLastRemoteStreamCreatedTimestampBuilder() - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The last time a stream was created by the remote endpoint.
- getLastRemoteStreamCreatedTimestampFieldBuilder() - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The last time a stream was created by the remote endpoint.
- getLastRemoteStreamCreatedTimestampOrBuilder() - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The last time a stream was created by the remote endpoint.
- getLastRemoteStreamCreatedTimestampOrBuilder() - Method in class io.grpc.channelz.v1.SocketData
-
The last time a stream was created by the remote endpoint.
- getLastRemoteStreamCreatedTimestampOrBuilder() - Method in interface io.grpc.channelz.v1.SocketDataOrBuilder
-
The last time a stream was created by the remote endpoint.
- getLb() - Method in class io.grpc.util.MultiChildLoadBalancer.ChildLbState
- getLbPolicyConfig(Map<String, ?>) - Static method in class io.grpc.internal.PickFirstLoadBalancerProvider
- getLength() - Method in class io.grpc.binarylog.v1.Message.Builder
-
Length of the message.
- getLength() - Method in class io.grpc.binarylog.v1.Message
-
Length of the message.
- getLength() - Method in interface io.grpc.binarylog.v1.MessageOrBuilder
-
Length of the message.
- getLifecycleManager() - Method in class io.grpc.netty.NettyClientHandler
- getLink() - Method in class io.grpc.netty.SendGrpcFrameCommand
- getLink() - Method in class io.grpc.netty.WriteQueue.AbstractQueuedCommand
- getLink() - Method in interface io.grpc.netty.WriteQueue.QueuedCommand
- getLink() - Method in class io.grpc.netty.WriteQueue.RunnableCommand
- getList(Map<String, ?>, String) - Static method in class io.grpc.internal.JsonUtil
-
Gets a list from an object for the given key.
- getListener() - Method in class io.grpc.internal.ServerImpl.JumpToApplicationThreadServerStreamListener
-
This call MUST be serialized on callExecutor to avoid races.
- getListenSocket(int) - Method in class io.grpc.channelz.v1.Server.Builder
-
The sockets that the server is listening on.
- getListenSocket(int) - Method in class io.grpc.channelz.v1.Server
-
The sockets that the server is listening on.
- getListenSocket(int) - Method in interface io.grpc.channelz.v1.ServerOrBuilder
-
The sockets that the server is listening on.
- getListenSocketAddress() - Method in class io.grpc.inprocess.InProcessServer
- getListenSocketAddress() - Method in interface io.grpc.internal.InternalServer
-
Returns the first listening socket address.
- getListenSocketAddress() - Method in class io.grpc.netty.NettyServer
- getListenSocketAddress() - Method in class io.grpc.servlet.jakarta.ServletServerBuilder.InternalServerImpl
- getListenSocketAddress() - Method in class io.grpc.servlet.ServletServerBuilder.InternalServerImpl
- getListenSocketAddresses() - Method in class io.grpc.inprocess.InProcessServer
- getListenSocketAddresses() - Method in interface io.grpc.internal.InternalServer
-
Returns a list of listening socket addresses.
- getListenSocketAddresses() - Method in class io.grpc.netty.NettyServer
- getListenSocketAddresses() - Method in class io.grpc.servlet.jakarta.ServletServerBuilder.InternalServerImpl
- getListenSocketAddresses() - Method in class io.grpc.servlet.ServletServerBuilder.InternalServerImpl
- getListenSocketBuilder(int) - Method in class io.grpc.channelz.v1.Server.Builder
-
The sockets that the server is listening on.
- getListenSocketBuilderList() - Method in class io.grpc.channelz.v1.Server.Builder
-
The sockets that the server is listening on.
- getListenSocketCount() - Method in class io.grpc.channelz.v1.Server.Builder
-
The sockets that the server is listening on.
- getListenSocketCount() - Method in class io.grpc.channelz.v1.Server
-
The sockets that the server is listening on.
- getListenSocketCount() - Method in interface io.grpc.channelz.v1.ServerOrBuilder
-
The sockets that the server is listening on.
- getListenSocketFieldBuilder() - Method in class io.grpc.channelz.v1.Server.Builder
- getListenSocketList() - Method in class io.grpc.channelz.v1.Server.Builder
-
The sockets that the server is listening on.
- getListenSocketList() - Method in class io.grpc.channelz.v1.Server
-
The sockets that the server is listening on.
- getListenSocketList() - Method in interface io.grpc.channelz.v1.ServerOrBuilder
-
The sockets that the server is listening on.
- getListenSocketOrBuilder(int) - Method in class io.grpc.channelz.v1.Server.Builder
-
The sockets that the server is listening on.
- getListenSocketOrBuilder(int) - Method in class io.grpc.channelz.v1.Server
-
The sockets that the server is listening on.
- getListenSocketOrBuilder(int) - Method in interface io.grpc.channelz.v1.ServerOrBuilder
-
The sockets that the server is listening on.
- getListenSocketOrBuilderList() - Method in class io.grpc.channelz.v1.Server.Builder
-
The sockets that the server is listening on.
- getListenSocketOrBuilderList() - Method in class io.grpc.channelz.v1.Server
-
The sockets that the server is listening on.
- getListenSocketOrBuilderList() - Method in interface io.grpc.channelz.v1.ServerOrBuilder
-
The sockets that the server is listening on.
- getListenSockets() - Method in class io.grpc.internal.ServerImpl
- getListenSockets() - Method in class io.grpc.Server
-
Returns a list of listening sockets for this server.
- getListenSocketsIgnoringLifecycle() - Method in class io.grpc.internal.ServerImpl
- getListenSocketStats() - Method in class io.grpc.inprocess.InProcessServer
- getListenSocketStats() - Method in interface io.grpc.internal.InternalServer
-
Returns the first listen socket stats of this server.
- getListenSocketStats() - Method in class io.grpc.netty.NettyServer
- getListenSocketStats() - Method in class io.grpc.servlet.jakarta.ServletServerBuilder.InternalServerImpl
- getListenSocketStats() - Method in class io.grpc.servlet.ServletServerBuilder.InternalServerImpl
- getListenSocketStatsList() - Method in class io.grpc.inprocess.InProcessServer
- getListenSocketStatsList() - Method in interface io.grpc.internal.InternalServer
-
Returns a list of listen socket stats of this server.
- getListenSocketStatsList() - Method in class io.grpc.netty.NettyServer
- getListenSocketStatsList() - Method in class io.grpc.servlet.jakarta.ServletServerBuilder.InternalServerImpl
- getListenSocketStatsList() - Method in class io.grpc.servlet.ServletServerBuilder.InternalServerImpl
- getListOfObjects(Map<String, ?>, String) - Static method in class io.grpc.internal.JsonUtil
-
Gets a list from an object for the given key, and verifies all entries are objects.
- getListOfStatusCodesAsSet(Map<String, ?>, String) - Static method in class io.grpc.internal.ServiceConfigUtil
- getListOfStrings(Map<String, ?>, String) - Static method in class io.grpc.internal.JsonUtil
-
Gets a list from an object for the given key, and verifies all entries are strings.
- getListServices() - Method in class io.grpc.reflection.v1.ServerReflectionRequest.Builder
-
List the full names of registered services.
- getListServices() - Method in class io.grpc.reflection.v1.ServerReflectionRequest
-
List the full names of registered services.
- getListServices() - Method in interface io.grpc.reflection.v1.ServerReflectionRequestOrBuilder
-
List the full names of registered services.
- getListServices() - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest.Builder
-
List the full names of registered services.
- getListServices() - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest
-
List the full names of registered services.
- getListServices() - Method in interface io.grpc.reflection.v1alpha.ServerReflectionRequestOrBuilder
-
List the full names of registered services.
- getListServicesBytes() - Method in class io.grpc.reflection.v1.ServerReflectionRequest.Builder
-
List the full names of registered services.
- getListServicesBytes() - Method in class io.grpc.reflection.v1.ServerReflectionRequest
-
List the full names of registered services.
- getListServicesBytes() - Method in interface io.grpc.reflection.v1.ServerReflectionRequestOrBuilder
-
List the full names of registered services.
- getListServicesBytes() - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest.Builder
-
List the full names of registered services.
- getListServicesBytes() - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest
-
List the full names of registered services.
- getListServicesBytes() - Method in interface io.grpc.reflection.v1alpha.ServerReflectionRequestOrBuilder
-
List the full names of registered services.
- getListServicesResponse() - Method in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
-
This message is used to answer list_services requests.
- getListServicesResponse() - Method in class io.grpc.reflection.v1.ServerReflectionResponse
-
This message is used to answer list_services requests.
- getListServicesResponse() - Method in interface io.grpc.reflection.v1.ServerReflectionResponseOrBuilder
-
This message is used to answer list_services requests.
- getListServicesResponse() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
-
This message is used to answer list_services request.
- getListServicesResponse() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse
-
This message is used to answer list_services request.
- getListServicesResponse() - Method in interface io.grpc.reflection.v1alpha.ServerReflectionResponseOrBuilder
-
This message is used to answer list_services request.
- getListServicesResponseBuilder() - Method in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
-
This message is used to answer list_services requests.
- getListServicesResponseBuilder() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
-
This message is used to answer list_services request.
- getListServicesResponseFieldBuilder() - Method in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
-
This message is used to answer list_services requests.
- getListServicesResponseFieldBuilder() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
-
This message is used to answer list_services request.
- getListServicesResponseOrBuilder() - Method in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
-
This message is used to answer list_services requests.
- getListServicesResponseOrBuilder() - Method in class io.grpc.reflection.v1.ServerReflectionResponse
-
This message is used to answer list_services requests.
- getListServicesResponseOrBuilder() - Method in interface io.grpc.reflection.v1.ServerReflectionResponseOrBuilder
-
This message is used to answer list_services requests.
- getListServicesResponseOrBuilder() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
-
This message is used to answer list_services request.
- getListServicesResponseOrBuilder() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse
-
This message is used to answer list_services request.
- getListServicesResponseOrBuilder() - Method in interface io.grpc.reflection.v1alpha.ServerReflectionResponseOrBuilder
-
This message is used to answer list_services request.
- getLoadBalanceRequestTypeCase() - Method in class io.grpc.lb.v1.LoadBalanceRequest.Builder
- getLoadBalanceRequestTypeCase() - Method in class io.grpc.lb.v1.LoadBalanceRequest
- getLoadBalanceRequestTypeCase() - Method in interface io.grpc.lb.v1.LoadBalanceRequestOrBuilder
- getLoadBalanceResponseTypeCase() - Method in class io.grpc.lb.v1.LoadBalanceResponse.Builder
- getLoadBalanceResponseTypeCase() - Method in class io.grpc.lb.v1.LoadBalanceResponse
- getLoadBalanceResponseTypeCase() - Method in interface io.grpc.lb.v1.LoadBalanceResponseOrBuilder
- getLoadBalanceToken() - Method in class io.grpc.lb.v1.ClientStatsPerToken.Builder
-
See Server.load_balance_token.
- getLoadBalanceToken() - Method in class io.grpc.lb.v1.ClientStatsPerToken
-
See Server.load_balance_token.
- getLoadBalanceToken() - Method in interface io.grpc.lb.v1.ClientStatsPerTokenOrBuilder
-
See Server.load_balance_token.
- getLoadBalanceToken() - Method in class io.grpc.lb.v1.Server.Builder
-
An opaque but printable token for load reporting.
- getLoadBalanceToken() - Method in class io.grpc.lb.v1.Server
-
An opaque but printable token for load reporting.
- getLoadBalanceToken() - Method in interface io.grpc.lb.v1.ServerOrBuilder
-
An opaque but printable token for load reporting.
- getLoadBalanceTokenBytes() - Method in class io.grpc.lb.v1.ClientStatsPerToken.Builder
-
See Server.load_balance_token.
- getLoadBalanceTokenBytes() - Method in class io.grpc.lb.v1.ClientStatsPerToken
-
See Server.load_balance_token.
- getLoadBalanceTokenBytes() - Method in interface io.grpc.lb.v1.ClientStatsPerTokenOrBuilder
-
See Server.load_balance_token.
- getLoadBalanceTokenBytes() - Method in class io.grpc.lb.v1.Server.Builder
-
An opaque but printable token for load reporting.
- getLoadBalanceTokenBytes() - Method in class io.grpc.lb.v1.Server
-
An opaque but printable token for load reporting.
- getLoadBalanceTokenBytes() - Method in interface io.grpc.lb.v1.ServerOrBuilder
-
An opaque but printable token for load reporting.
- getLoadBalancingConfig() - Method in class io.grpc.internal.ManagedChannelServiceConfig
- getLoadBalancingConfigsFromServiceConfig(Map<String, ?>) - Static method in class io.grpc.internal.ServiceConfigUtil
-
Extracts load balancing configs from a service config.
- getLoadBalancingPolicy() - Method in class io.grpc.rls.LbPolicyConfiguration
- getLoadBalancingPolicyConfig() - Method in class io.grpc.LoadBalancer.ResolvedAddresses
-
Gets the domain specific load balancing policy.
- getLoadRecorder() - Method in class io.grpc.grpclb.GrpclbState
- getLocal() - Method in class io.grpc.channelz.v1.Socket.Builder
-
The locally bound address.
- getLocal() - Method in class io.grpc.channelz.v1.Socket
-
The locally bound address.
- getLocal() - Method in interface io.grpc.channelz.v1.SocketOrBuilder
-
The locally bound address.
- getLocalBuilder() - Method in class io.grpc.channelz.v1.Socket.Builder
-
The locally bound address.
- getLocalCertificate() - Method in class io.grpc.channelz.v1.Security.Tls.Builder
-
the certificate used by this endpoint.
- getLocalCertificate() - Method in class io.grpc.channelz.v1.Security.Tls
-
the certificate used by this endpoint.
- getLocalCertificate() - Method in interface io.grpc.channelz.v1.Security.TlsOrBuilder
-
the certificate used by this endpoint.
- getLocalFieldBuilder() - Method in class io.grpc.channelz.v1.Socket.Builder
-
The locally bound address.
- getLocalFlowControlWindow() - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The amount of window, granted to the local endpoint by the remote endpoint.
- getLocalFlowControlWindow() - Method in class io.grpc.channelz.v1.SocketData
-
The amount of window, granted to the local endpoint by the remote endpoint.
- getLocalFlowControlWindow() - Method in interface io.grpc.channelz.v1.SocketDataOrBuilder
-
The amount of window, granted to the local endpoint by the remote endpoint.
- getLocalFlowControlWindowBuilder() - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The amount of window, granted to the local endpoint by the remote endpoint.
- getLocalFlowControlWindowFieldBuilder() - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The amount of window, granted to the local endpoint by the remote endpoint.
- getLocalFlowControlWindowOrBuilder() - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The amount of window, granted to the local endpoint by the remote endpoint.
- getLocalFlowControlWindowOrBuilder() - Method in class io.grpc.channelz.v1.SocketData
-
The amount of window, granted to the local endpoint by the remote endpoint.
- getLocalFlowControlWindowOrBuilder() - Method in interface io.grpc.channelz.v1.SocketDataOrBuilder
-
The amount of window, granted to the local endpoint by the remote endpoint.
- getLocalHostname() - Static method in class io.grpc.internal.DnsNameResolver
- getLocalOrBuilder() - Method in class io.grpc.channelz.v1.Socket.Builder
-
The locally bound address.
- getLocalOrBuilder() - Method in class io.grpc.channelz.v1.Socket
-
The locally bound address.
- getLocalOrBuilder() - Method in interface io.grpc.channelz.v1.SocketOrBuilder
-
The locally bound address.
- getLog(String) - Method in interface io.grpc.protobuf.services.BinlogHelper.Factory
- getLog(String) - Method in class io.grpc.protobuf.services.BinlogHelper.FactoryImpl
-
Accepts a full method name and returns the log that should be used.
- getLogger() - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
One of the above Logger enum
- getLogger() - Method in class io.grpc.binarylog.v1.GrpcLogEntry
-
One of the above Logger enum
- getLogger() - Method in interface io.grpc.binarylog.v1.GrpcLogEntryOrBuilder
-
One of the above Logger enum
- getLoggerValue() - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
One of the above Logger enum
- getLoggerValue() - Method in class io.grpc.binarylog.v1.GrpcLogEntry
-
One of the above Logger enum
- getLoggerValue() - Method in interface io.grpc.binarylog.v1.GrpcLogEntryOrBuilder
-
One of the above Logger enum
- getLogId() - Method in class io.grpc.inprocess.InProcessTransport
- getLogId() - Method in class io.grpc.internal.ChannelTracer
- getLogId() - Method in class io.grpc.internal.DelayedClientTransport
- getLogId() - Method in class io.grpc.internal.FailingClientTransport
- getLogId() - Method in class io.grpc.internal.ForwardingConnectionClientTransport
- getLogId() - Method in class io.grpc.internal.InternalSubchannel
- getLogId() - Method in class io.grpc.internal.ManagedChannelImpl
- getLogId() - Method in class io.grpc.internal.OobChannel
- 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.
- getLogId() - Method in class io.grpc.netty.NettyClientTransport
- getLogId() - Method in class io.grpc.netty.NettyServer
- getLogId() - Method in class io.grpc.netty.NettyServer.ListenSocket
- getLogId() - Method in class io.grpc.netty.NettyServerTransport
- getLogId() - Method in class io.grpc.servlet.jakarta.ServletServerBuilder.ServerTransportImpl
- getLogId() - Method in class io.grpc.servlet.ServletServerBuilder.ServerTransportImpl
- getLogLevel(Throwable) - Static method in class io.grpc.netty.NettyServerTransport
-
Accepts a throwable and returns the appropriate logging level.
- getLong(CharSequence) - Method in class io.grpc.netty.AbstractHttp2Headers
- getLong(CharSequence, long) - Method in class io.grpc.netty.AbstractHttp2Headers
- getLongAndRemove(CharSequence) - Method in class io.grpc.netty.AbstractHttp2Headers
- getLongAndRemove(CharSequence, long) - Method in class io.grpc.netty.AbstractHttp2Headers
- getLookupService() - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
The name of the lookup service as a gRPC URI.
- getLookupService() - Method in class io.grpc.lookup.v1.RouteLookupConfig
-
The name of the lookup service as a gRPC URI.
- getLookupService() - Method in interface io.grpc.lookup.v1.RouteLookupConfigOrBuilder
-
The name of the lookup service as a gRPC URI.
- getLookupServiceBytes() - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
The name of the lookup service as a gRPC URI.
- getLookupServiceBytes() - Method in class io.grpc.lookup.v1.RouteLookupConfig
-
The name of the lookup service as a gRPC URI.
- getLookupServiceBytes() - Method in interface io.grpc.lookup.v1.RouteLookupConfigOrBuilder
-
The name of the lookup service as a gRPC URI.
- getLookupServiceTimeout() - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
Configure a timeout value for lookup service requests.
- getLookupServiceTimeout() - Method in class io.grpc.lookup.v1.RouteLookupConfig
-
Configure a timeout value for lookup service requests.
- getLookupServiceTimeout() - Method in interface io.grpc.lookup.v1.RouteLookupConfigOrBuilder
-
Configure a timeout value for lookup service requests.
- getLookupServiceTimeoutBuilder() - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
Configure a timeout value for lookup service requests.
- getLookupServiceTimeoutFieldBuilder() - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
Configure a timeout value for lookup service requests.
- getLookupServiceTimeoutOrBuilder() - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
Configure a timeout value for lookup service requests.
- getLookupServiceTimeoutOrBuilder() - Method in class io.grpc.lookup.v1.RouteLookupConfig
-
Configure a timeout value for lookup service requests.
- getLookupServiceTimeoutOrBuilder() - Method in interface io.grpc.lookup.v1.RouteLookupConfigOrBuilder
-
Configure a timeout value for lookup service requests.
- getMarshaller(Class<M>) - Method in class io.grpc.Metadata.Key
-
Gets this keys (implementation-specific) marshaller, or null if the marshaller is not of the given type.
- getMaxAge() - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
How long are responses valid for (like HTTP Cache-Control).
- getMaxAge() - Method in class io.grpc.lookup.v1.RouteLookupConfig
-
How long are responses valid for (like HTTP Cache-Control).
- getMaxAge() - Method in interface io.grpc.lookup.v1.RouteLookupConfigOrBuilder
-
How long are responses valid for (like HTTP Cache-Control).
- getMaxAgeBuilder() - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
How long are responses valid for (like HTTP Cache-Control).
- getMaxAgeFieldBuilder() - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
How long are responses valid for (like HTTP Cache-Control).
- getMaxAgeOrBuilder() - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
How long are responses valid for (like HTTP Cache-Control).
- getMaxAgeOrBuilder() - Method in class io.grpc.lookup.v1.RouteLookupConfig
-
How long are responses valid for (like HTTP Cache-Control).
- getMaxAgeOrBuilder() - Method in interface io.grpc.lookup.v1.RouteLookupConfigOrBuilder
-
How long are responses valid for (like HTTP Cache-Control).
- getMaxAttemptsFromHedgingPolicy(Map<String, ?>) - Static method in class io.grpc.internal.ServiceConfigUtil
- getMaxAttemptsFromRetryPolicy(Map<String, ?>) - Static method in class io.grpc.internal.ServiceConfigUtil
- getMaxBackoffNanosFromRetryPolicy(Map<String, ?>) - Static method in class io.grpc.internal.ServiceConfigUtil
- getMaxHeaderBytes() - Method in class io.grpc.protobuf.services.BinlogHelper.SinkWriter
-
Returns the number bytes of the header this writer will log, according to configuration.
- getMaxHeaderBytes() - Method in class io.grpc.protobuf.services.BinlogHelper.SinkWriterImpl
- getMaxInboundMessageSize() - Method in class io.grpc.CallOptions
-
Gets the maximum allowed message size acceptable from the remote peer.
- getMaxInboundMetadataSize() - Method in class io.grpc.inprocess.InProcessServer
- getMaxMessageBytes() - Method in class io.grpc.protobuf.services.BinlogHelper.SinkWriter
-
Returns the number bytes of the message this writer will log, according to configuration.
- getMaxMessageBytes() - Method in class io.grpc.protobuf.services.BinlogHelper.SinkWriterImpl
- getMaxOutboundMessageSize() - Method in class io.grpc.CallOptions
-
Gets the maximum allowed message size acceptable to send the remote peer.
- getMaxRequestMessageBytesFromMethodConfig(Map<String, ?>) - Static method in class io.grpc.internal.ServiceConfigUtil
- getMaxResponseMessageBytesFromMethodConfig(Map<String, ?>) - Static method in class io.grpc.internal.ServiceConfigUtil
- getMaxResults() - Method in class io.grpc.channelz.v1.GetServerSocketsRequest.Builder
-
If non-zero, the server will return a page of results containing at most this many items.
- getMaxResults() - Method in class io.grpc.channelz.v1.GetServerSocketsRequest
-
If non-zero, the server will return a page of results containing at most this many items.
- getMaxResults() - Method in interface io.grpc.channelz.v1.GetServerSocketsRequestOrBuilder
-
If non-zero, the server will return a page of results containing at most this many items.
- getMaxResults() - Method in class io.grpc.channelz.v1.GetServersRequest.Builder
-
If non-zero, the server will return a page of results containing at most this many items.
- getMaxResults() - Method in class io.grpc.channelz.v1.GetServersRequest
-
If non-zero, the server will return a page of results containing at most this many items.
- getMaxResults() - Method in interface io.grpc.channelz.v1.GetServersRequestOrBuilder
-
If non-zero, the server will return a page of results containing at most this many items.
- getMaxResults() - Method in class io.grpc.channelz.v1.GetTopChannelsRequest.Builder
-
If non-zero, the server will return a page of results containing at most this many items.
- getMaxResults() - Method in class io.grpc.channelz.v1.GetTopChannelsRequest
-
If non-zero, the server will return a page of results containing at most this many items.
- getMaxResults() - Method in interface io.grpc.channelz.v1.GetTopChannelsRequestOrBuilder
-
If non-zero, the server will return a page of results containing at most this many items.
- getMeasuresSize() - Method in interface io.grpc.MetricSink
-
Returns size of metric measures used to record metric values.
- getMemoryUtilization() - Method in class io.grpc.services.MetricReport
- getMessage() - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
Used by EVENT_TYPE_CLIENT_MESSAGE, EVENT_TYPE_SERVER_MESSAGE
- getMessage() - Method in class io.grpc.binarylog.v1.GrpcLogEntry
-
Used by EVENT_TYPE_CLIENT_MESSAGE, EVENT_TYPE_SERVER_MESSAGE
- getMessage() - Method in interface io.grpc.binarylog.v1.GrpcLogEntryOrBuilder
-
Used by EVENT_TYPE_CLIENT_MESSAGE, EVENT_TYPE_SERVER_MESSAGE
- getMessageBuilder() - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
Used by EVENT_TYPE_CLIENT_MESSAGE, EVENT_TYPE_SERVER_MESSAGE
- getMessageClass() - Method in interface io.grpc.MethodDescriptor.ReflectableMarshaller
-
Returns the
Class
that this marshaller serializes and deserializes. - getMessageClass() - Method in class io.grpc.protobuf.lite.ProtoLiteUtils.MessageMarshaller
- 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.
- getMessageFieldBuilder() - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
Used by EVENT_TYPE_CLIENT_MESSAGE, EVENT_TYPE_SERVER_MESSAGE
- getMessageOrBuilder() - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
Used by EVENT_TYPE_CLIENT_MESSAGE, EVENT_TYPE_SERVER_MESSAGE
- getMessageOrBuilder() - Method in class io.grpc.binarylog.v1.GrpcLogEntry
-
Used by EVENT_TYPE_CLIENT_MESSAGE, EVENT_TYPE_SERVER_MESSAGE
- getMessageOrBuilder() - Method in interface io.grpc.binarylog.v1.GrpcLogEntryOrBuilder
-
Used by EVENT_TYPE_CLIENT_MESSAGE, EVENT_TYPE_SERVER_MESSAGE
- 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.
- getMessagePrototype() - Method in class io.grpc.protobuf.lite.ProtoLiteUtils.MessageMarshaller
- getMessageRequestCase() - Method in class io.grpc.reflection.v1.ServerReflectionRequest.Builder
- getMessageRequestCase() - Method in class io.grpc.reflection.v1.ServerReflectionRequest
- getMessageRequestCase() - Method in interface io.grpc.reflection.v1.ServerReflectionRequestOrBuilder
- getMessageRequestCase() - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest.Builder
- getMessageRequestCase() - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest
- getMessageRequestCase() - Method in interface io.grpc.reflection.v1alpha.ServerReflectionRequestOrBuilder
- getMessageResponseCase() - Method in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
- getMessageResponseCase() - Method in class io.grpc.reflection.v1.ServerReflectionResponse
- getMessageResponseCase() - Method in interface io.grpc.reflection.v1.ServerReflectionResponseOrBuilder
- getMessageResponseCase() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
- getMessageResponseCase() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse
- getMessageResponseCase() - Method in interface io.grpc.reflection.v1alpha.ServerReflectionResponseOrBuilder
- getMessagesReceived() - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The number of grpc messages received on this socket.
- getMessagesReceived() - Method in class io.grpc.channelz.v1.SocketData
-
The number of grpc messages received on this socket.
- getMessagesReceived() - Method in interface io.grpc.channelz.v1.SocketDataOrBuilder
-
The number of grpc messages received on this socket.
- getMessagesSent() - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The number of grpc messages successfully sent on this socket.
- getMessagesSent() - Method in class io.grpc.channelz.v1.SocketData
-
The number of grpc messages successfully sent on this socket.
- getMessagesSent() - Method in interface io.grpc.channelz.v1.SocketDataOrBuilder
-
The number of grpc messages successfully sent on this socket.
- getMetadata() - Method in class io.grpc.binarylog.v1.ClientHeader.Builder
-
This contains only the metadata from the application.
- getMetadata() - Method in class io.grpc.binarylog.v1.ClientHeader
-
This contains only the metadata from the application.
- getMetadata() - Method in interface io.grpc.binarylog.v1.ClientHeaderOrBuilder
-
This contains only the metadata from the application.
- getMetadata() - Method in class io.grpc.binarylog.v1.ServerHeader.Builder
-
This contains only the metadata from the application.
- getMetadata() - Method in class io.grpc.binarylog.v1.ServerHeader
-
This contains only the metadata from the application.
- getMetadata() - Method in interface io.grpc.binarylog.v1.ServerHeaderOrBuilder
-
This contains only the metadata from the application.
- getMetadata() - Method in class io.grpc.binarylog.v1.Trailer.Builder
-
This contains only the metadata from the application.
- getMetadata() - Method in class io.grpc.binarylog.v1.Trailer
-
This contains only the metadata from the application.
- getMetadata() - Method in interface io.grpc.binarylog.v1.TrailerOrBuilder
-
This contains only the metadata from the application.
- getMetadataBuilder() - Method in class io.grpc.binarylog.v1.ClientHeader.Builder
-
This contains only the metadata from the application.
- getMetadataBuilder() - Method in class io.grpc.binarylog.v1.ServerHeader.Builder
-
This contains only the metadata from the application.
- getMetadataBuilder() - Method in class io.grpc.binarylog.v1.Trailer.Builder
-
This contains only the metadata from the application.
- getMetadataFieldBuilder() - Method in class io.grpc.binarylog.v1.ClientHeader.Builder
-
This contains only the metadata from the application.
- getMetadataFieldBuilder() - Method in class io.grpc.binarylog.v1.ServerHeader.Builder
-
This contains only the metadata from the application.
- getMetadataFieldBuilder() - Method in class io.grpc.binarylog.v1.Trailer.Builder
-
This contains only the metadata from the application.
- getMetadataOrBuilder() - Method in class io.grpc.binarylog.v1.ClientHeader.Builder
-
This contains only the metadata from the application.
- getMetadataOrBuilder() - Method in class io.grpc.binarylog.v1.ClientHeader
-
This contains only the metadata from the application.
- getMetadataOrBuilder() - Method in interface io.grpc.binarylog.v1.ClientHeaderOrBuilder
-
This contains only the metadata from the application.
- getMetadataOrBuilder() - Method in class io.grpc.binarylog.v1.ServerHeader.Builder
-
This contains only the metadata from the application.
- getMetadataOrBuilder() - Method in class io.grpc.binarylog.v1.ServerHeader
-
This contains only the metadata from the application.
- getMetadataOrBuilder() - Method in interface io.grpc.binarylog.v1.ServerHeaderOrBuilder
-
This contains only the metadata from the application.
- getMetadataOrBuilder() - Method in class io.grpc.binarylog.v1.Trailer.Builder
-
This contains only the metadata from the application.
- getMetadataOrBuilder() - Method in class io.grpc.binarylog.v1.Trailer
-
This contains only the metadata from the application.
- getMetadataOrBuilder() - Method in interface io.grpc.binarylog.v1.TrailerOrBuilder
-
This contains only the metadata from the application.
- getMethod() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys.Builder
-
string method = 3;
- getMethod() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys
-
string method = 3;
- getMethod() - Method in interface io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeysOrBuilder
-
string method = 3;
- getMethod() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Name.Builder
-
string method = 2;
- getMethod() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Name
-
string method = 2;
- getMethod() - Method in interface io.grpc.lookup.v1.GrpcKeyBuilder.NameOrBuilder
-
string method = 2;
- getMethod(String) - Method in class io.grpc.ServerServiceDefinition
-
Look up a method by its fully qualified name.
- getMethodBytes() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys.Builder
-
string method = 3;
- getMethodBytes() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys
-
string method = 3;
- getMethodBytes() - Method in interface io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeysOrBuilder
-
string method = 3;
- getMethodBytes() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Name.Builder
-
string method = 2;
- getMethodBytes() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Name
-
string method = 2;
- getMethodBytes() - Method in interface io.grpc.lookup.v1.GrpcKeyBuilder.NameOrBuilder
-
string method = 2;
- getMethodConfig(MethodDescriptor<?, ?>) - Method in class io.grpc.internal.ManagedChannelServiceConfig
- getMethodConfigFromServiceConfig(Map<String, ?>) - Static method in class io.grpc.internal.ServiceConfigUtil
- getMethodDescriptor() - Method in class io.grpc.CallCredentials.RequestInfo
-
The method descriptor of this RPC.
- getMethodDescriptor() - Method in class io.grpc.channelz.v1.ChannelzGrpc.ChannelzMethodDescriptorSupplier
- getMethodDescriptor() - Method in class io.grpc.ForwardingServerCall
- getMethodDescriptor() - Method in class io.grpc.health.v1.HealthGrpc.HealthMethodDescriptorSupplier
- getMethodDescriptor() - Method in class io.grpc.internal.PickSubchannelArgsImpl
- getMethodDescriptor() - Method in class io.grpc.internal.ServerCallImpl
- getMethodDescriptor() - Method in class io.grpc.internal.ServerCallInfoImpl
- getMethodDescriptor() - Method in class io.grpc.lb.v1.LoadBalancerGrpc.LoadBalancerMethodDescriptorSupplier
- getMethodDescriptor() - Method in class io.grpc.LoadBalancer.PickSubchannelArgs
-
Call method.
- getMethodDescriptor() - Method in class io.grpc.lookup.v1.RouteLookupServiceGrpc.RouteLookupServiceMethodDescriptorSupplier
- getMethodDescriptor() - Method in interface io.grpc.protobuf.ProtoMethodDescriptorSupplier
-
Returns method descriptor to the proto service method.
- getMethodDescriptor() - Method in class io.grpc.reflection.v1.ServerReflectionGrpc.ServerReflectionMethodDescriptorSupplier
- getMethodDescriptor() - Method in class io.grpc.reflection.v1alpha.ServerReflectionGrpc.ServerReflectionMethodDescriptorSupplier
- getMethodDescriptor() - Method in class io.grpc.ServerCall
-
The
MethodDescriptor
for the call. - getMethodDescriptor() - Method in class io.grpc.ServerMethodDefinition
-
The
MethodDescriptor
for this method. - getMethodDescriptor() - Method in class io.grpc.ServerStreamTracer.ReadOnlyServerCall
-
Deprecated.
- getMethodDescriptor() - Method in class io.grpc.ServerStreamTracer.ServerCallInfo
- getMethodFromName(Map<String, ?>) - Static method in class io.grpc.internal.ServiceConfigUtil
- getMethodName() - Method in class io.grpc.binarylog.v1.ClientHeader.Builder
-
The name of the RPC method, which looks something like: /<service>/<method> Note the leading "/" character.
- getMethodName() - Method in class io.grpc.binarylog.v1.ClientHeader
-
The name of the RPC method, which looks something like: /<service>/<method> Note the leading "/" character.
- getMethodName() - Method in interface io.grpc.binarylog.v1.ClientHeaderOrBuilder
-
The name of the RPC method, which looks something like: /<service>/<method> Note the leading "/" character.
- getMethodNameBytes() - Method in class io.grpc.binarylog.v1.ClientHeader.Builder
-
The name of the RPC method, which looks something like: /<service>/<method> Note the leading "/" character.
- getMethodNameBytes() - Method in class io.grpc.binarylog.v1.ClientHeader
-
The name of the RPC method, which looks something like: /<service>/<method> Note the leading "/" character.
- getMethodNameBytes() - Method in interface io.grpc.binarylog.v1.ClientHeaderOrBuilder
-
The name of the RPC method, which looks something like: /<service>/<method> Note the leading "/" character.
- 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. - getMetricInstruments() - Method in class io.grpc.MetricInstrumentRegistry
-
Returns a list of registered metric instruments.
- getMetricRecorder() - Method in class io.grpc.internal.ManagedChannelImpl.LbHelperImpl
- getMetricRecorder() - Method in class io.grpc.LoadBalancer.Helper
-
Returns the
MetricRecorder
that the channel uses to record metrics. - getMetricRecorder() - Method in class io.grpc.util.ForwardingLoadBalancerHelper
- getMetricReport() - Method in class io.grpc.services.MetricRecorder
- getMetricReport(MetricRecorder) - Static method in class io.grpc.services.InternalMetricRecorder
- getMode() - Method in class io.grpc.grpclb.GrpclbConfig
- getModelCase() - Method in class io.grpc.channelz.v1.Security.Builder
- getModelCase() - Method in class io.grpc.channelz.v1.Security
- getModelCase() - Method in interface io.grpc.channelz.v1.SecurityOrBuilder
- getMutableConstantKeys() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
-
Deprecated.
- getMutableConstantKeys() - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
-
Deprecated.
- getMutableKeyMap() - Method in class io.grpc.lookup.v1.RouteLookupRequest.Builder
-
Deprecated.
- 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.
- getMutableServicesIndex() - Method in class io.grpc.protobuf.services.ProtoReflectionServiceV1.ServerReflectionIndex
- getName() - Method in class io.grpc.channelz.v1.Address.OtherAddress.Builder
-
The human readable version of the value.
- getName() - Method in class io.grpc.channelz.v1.Address.OtherAddress
-
The human readable version of the value.
- getName() - Method in interface io.grpc.channelz.v1.Address.OtherAddressOrBuilder
-
The human readable version of the value.
- getName() - Method in class io.grpc.channelz.v1.ChannelRef.Builder
-
An optional name associated with the channel.
- getName() - Method in class io.grpc.channelz.v1.ChannelRef
-
An optional name associated with the channel.
- getName() - Method in interface io.grpc.channelz.v1.ChannelRefOrBuilder
-
An optional name associated with the channel.
- getName() - Method in class io.grpc.channelz.v1.Security.OtherSecurity.Builder
-
The human readable version of the value.
- getName() - Method in class io.grpc.channelz.v1.Security.OtherSecurity
-
The human readable version of the value.
- getName() - Method in interface io.grpc.channelz.v1.Security.OtherSecurityOrBuilder
-
The human readable version of the value.
- getName() - Method in class io.grpc.channelz.v1.ServerRef.Builder
-
An optional name associated with the server.
- getName() - Method in class io.grpc.channelz.v1.ServerRef
-
An optional name associated with the server.
- getName() - Method in interface io.grpc.channelz.v1.ServerRefOrBuilder
-
An optional name associated with the server.
- getName() - Method in class io.grpc.channelz.v1.SocketOption.Builder
-
The full name of the socket option.
- getName() - Method in class io.grpc.channelz.v1.SocketOption
-
The full name of the socket option.
- getName() - Method in interface io.grpc.channelz.v1.SocketOptionOrBuilder
-
The full name of the socket option.
- getName() - Method in class io.grpc.channelz.v1.SocketRef.Builder
-
An optional name associated with the socket.
- getName() - Method in class io.grpc.channelz.v1.SocketRef
-
An optional name associated with the socket.
- getName() - Method in interface io.grpc.channelz.v1.SocketRefOrBuilder
-
An optional name associated with the socket.
- getName() - Method in class io.grpc.channelz.v1.SubchannelRef.Builder
-
An optional name associated with the subchannel.
- getName() - Method in class io.grpc.channelz.v1.SubchannelRef
-
An optional name associated with the subchannel.
- getName() - Method in interface io.grpc.channelz.v1.SubchannelRefOrBuilder
-
An optional name associated with the subchannel.
- getName() - Method in class io.grpc.inprocess.InProcessSocketAddress
-
Gets the name of the inprocess server.
- getName() - Method in class io.grpc.lb.v1.InitialLoadBalanceRequest.Builder
-
The name of the load balanced service (e.g., service.googleapis.com).
- getName() - Method in class io.grpc.lb.v1.InitialLoadBalanceRequest
-
The name of the load balanced service (e.g., service.googleapis.com).
- getName() - Method in interface io.grpc.lb.v1.InitialLoadBalanceRequestOrBuilder
-
The name of the load balanced service (e.g., service.googleapis.com).
- getName() - Method in interface io.grpc.MetricInstrument
-
Returns the name of the metric.
- getName() - Method in class io.grpc.PartialMetricInstrument
- getName() - Method in class io.grpc.reflection.v1.ServiceResponse.Builder
-
Full name of a registered service, including its package name.
- getName() - Method in class io.grpc.reflection.v1.ServiceResponse
-
Full name of a registered service, including its package name.
- getName() - Method in interface io.grpc.reflection.v1.ServiceResponseOrBuilder
-
Full name of a registered service, including its package name.
- getName() - Method in class io.grpc.reflection.v1alpha.ServiceResponse.Builder
-
Full name of a registered service, including its package name.
- getName() - Method in class io.grpc.reflection.v1alpha.ServiceResponse
-
Full name of a registered service, including its package name.
- getName() - Method in interface io.grpc.reflection.v1alpha.ServiceResponseOrBuilder
-
Full name of a registered service, including its package name.
- getName() - Method in class io.grpc.ServiceDescriptor
-
Simple name of the service.
- getNameBytes() - Method in class io.grpc.channelz.v1.Address.OtherAddress.Builder
-
The human readable version of the value.
- getNameBytes() - Method in class io.grpc.channelz.v1.Address.OtherAddress
-
The human readable version of the value.
- getNameBytes() - Method in interface io.grpc.channelz.v1.Address.OtherAddressOrBuilder
-
The human readable version of the value.
- getNameBytes() - Method in class io.grpc.channelz.v1.ChannelRef.Builder
-
An optional name associated with the channel.
- getNameBytes() - Method in class io.grpc.channelz.v1.ChannelRef
-
An optional name associated with the channel.
- getNameBytes() - Method in interface io.grpc.channelz.v1.ChannelRefOrBuilder
-
An optional name associated with the channel.
- getNameBytes() - Method in class io.grpc.channelz.v1.Security.OtherSecurity.Builder
-
The human readable version of the value.
- getNameBytes() - Method in class io.grpc.channelz.v1.Security.OtherSecurity
-
The human readable version of the value.
- getNameBytes() - Method in interface io.grpc.channelz.v1.Security.OtherSecurityOrBuilder
-
The human readable version of the value.
- getNameBytes() - Method in class io.grpc.channelz.v1.ServerRef.Builder
-
An optional name associated with the server.
- getNameBytes() - Method in class io.grpc.channelz.v1.ServerRef
-
An optional name associated with the server.
- getNameBytes() - Method in interface io.grpc.channelz.v1.ServerRefOrBuilder
-
An optional name associated with the server.
- getNameBytes() - Method in class io.grpc.channelz.v1.SocketOption.Builder
-
The full name of the socket option.
- getNameBytes() - Method in class io.grpc.channelz.v1.SocketOption
-
The full name of the socket option.
- getNameBytes() - Method in interface io.grpc.channelz.v1.SocketOptionOrBuilder
-
The full name of the socket option.
- getNameBytes() - Method in class io.grpc.channelz.v1.SocketRef.Builder
-
An optional name associated with the socket.
- getNameBytes() - Method in class io.grpc.channelz.v1.SocketRef
-
An optional name associated with the socket.
- getNameBytes() - Method in interface io.grpc.channelz.v1.SocketRefOrBuilder
-
An optional name associated with the socket.
- getNameBytes() - Method in class io.grpc.channelz.v1.SubchannelRef.Builder
-
An optional name associated with the subchannel.
- getNameBytes() - Method in class io.grpc.channelz.v1.SubchannelRef
-
An optional name associated with the subchannel.
- getNameBytes() - Method in interface io.grpc.channelz.v1.SubchannelRefOrBuilder
-
An optional name associated with the subchannel.
- getNameBytes() - Method in class io.grpc.lb.v1.InitialLoadBalanceRequest.Builder
-
The name of the load balanced service (e.g., service.googleapis.com).
- getNameBytes() - Method in class io.grpc.lb.v1.InitialLoadBalanceRequest
-
The name of the load balanced service (e.g., service.googleapis.com).
- getNameBytes() - Method in interface io.grpc.lb.v1.InitialLoadBalanceRequestOrBuilder
-
The name of the load balanced service (e.g., service.googleapis.com).
- getNameBytes() - Method in class io.grpc.reflection.v1.ServiceResponse.Builder
-
Full name of a registered service, including its package name.
- getNameBytes() - Method in class io.grpc.reflection.v1.ServiceResponse
-
Full name of a registered service, including its package name.
- getNameBytes() - Method in interface io.grpc.reflection.v1.ServiceResponseOrBuilder
-
Full name of a registered service, including its package name.
- getNameBytes() - Method in class io.grpc.reflection.v1alpha.ServiceResponse.Builder
-
Full name of a registered service, including its package name.
- getNameBytes() - Method in class io.grpc.reflection.v1alpha.ServiceResponse
-
Full name of a registered service, including its package name.
- getNameBytes() - Method in interface io.grpc.reflection.v1alpha.ServiceResponseOrBuilder
-
Full name of a registered service, including its package name.
- getNamedMetrics() - Method in class io.grpc.services.MetricReport
- getNameListFromMethodConfig(Map<String, ?>) - Static method in class io.grpc.internal.ServiceConfigUtil
- getNameResolver(URI, String, NameResolverProvider, NameResolver.Args) - Static method in class io.grpc.internal.ManagedChannelImpl
- getNameResolverArgs() - Method in class io.grpc.internal.ManagedChannelImpl.LbHelperImpl
- getNameResolverArgs() - Method in class io.grpc.LoadBalancer.Helper
-
Returns the
NameResolver.Args
that the Channel uses to createNameResolver
s. - getNameResolverArgs() - Method in class io.grpc.util.ForwardingLoadBalancerHelper
- getNameResolverProvider(String, NameResolverRegistry, Collection<Class<? extends SocketAddress>>) - Static method in class io.grpc.internal.ManagedChannelImplBuilder
- getNameResolverRegistry() - Method in class io.grpc.internal.ManagedChannelImpl.LbHelperImpl
- getNameResolverRegistry() - Method in class io.grpc.LoadBalancer.Helper
-
Returns the
NameResolverRegistry
that the Channel uses to look forNameResolver
s. - getNameResolverRegistry() - Method in class io.grpc.util.ForwardingLoadBalancerHelper
- getNames(int) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
-
repeated .grpc.lookup.v1.GrpcKeyBuilder.Name names = 1;
- getNames(int) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder
-
repeated .grpc.lookup.v1.GrpcKeyBuilder.Name names = 1;
- getNames(int) - Method in interface io.grpc.lookup.v1.GrpcKeyBuilderOrBuilder
-
repeated .grpc.lookup.v1.GrpcKeyBuilder.Name names = 1;
- getNames(int) - Method in class io.grpc.lookup.v1.NameMatcher.Builder
-
Ordered list of names (headers or query parameter names) that can supply this value; the first one with a non-empty value is used.
- getNames(int) - Method in class io.grpc.lookup.v1.NameMatcher
-
Ordered list of names (headers or query parameter names) that can supply this value; the first one with a non-empty value is used.
- getNames(int) - Method in interface io.grpc.lookup.v1.NameMatcherOrBuilder
-
Ordered list of names (headers or query parameter names) that can supply this value; the first one with a non-empty value is used.
- getNamesBuilder(int) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
-
repeated .grpc.lookup.v1.GrpcKeyBuilder.Name names = 1;
- getNamesBuilderList() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
-
repeated .grpc.lookup.v1.GrpcKeyBuilder.Name names = 1;
- getNamesBytes(int) - Method in class io.grpc.lookup.v1.NameMatcher.Builder
-
Ordered list of names (headers or query parameter names) that can supply this value; the first one with a non-empty value is used.
- getNamesBytes(int) - Method in class io.grpc.lookup.v1.NameMatcher
-
Ordered list of names (headers or query parameter names) that can supply this value; the first one with a non-empty value is used.
- getNamesBytes(int) - Method in interface io.grpc.lookup.v1.NameMatcherOrBuilder
-
Ordered list of names (headers or query parameter names) that can supply this value; the first one with a non-empty value is used.
- getNamesCount() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
-
repeated .grpc.lookup.v1.GrpcKeyBuilder.Name names = 1;
- getNamesCount() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder
-
repeated .grpc.lookup.v1.GrpcKeyBuilder.Name names = 1;
- getNamesCount() - Method in interface io.grpc.lookup.v1.GrpcKeyBuilderOrBuilder
-
repeated .grpc.lookup.v1.GrpcKeyBuilder.Name names = 1;
- getNamesCount() - Method in class io.grpc.lookup.v1.NameMatcher.Builder
-
Ordered list of names (headers or query parameter names) that can supply this value; the first one with a non-empty value is used.
- getNamesCount() - Method in class io.grpc.lookup.v1.NameMatcher
-
Ordered list of names (headers or query parameter names) that can supply this value; the first one with a non-empty value is used.
- getNamesCount() - Method in interface io.grpc.lookup.v1.NameMatcherOrBuilder
-
Ordered list of names (headers or query parameter names) that can supply this value; the first one with a non-empty value is used.
- getNamesFieldBuilder() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
- getNamesList() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
-
repeated .grpc.lookup.v1.GrpcKeyBuilder.Name names = 1;
- getNamesList() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder
-
repeated .grpc.lookup.v1.GrpcKeyBuilder.Name names = 1;
- getNamesList() - Method in interface io.grpc.lookup.v1.GrpcKeyBuilderOrBuilder
-
repeated .grpc.lookup.v1.GrpcKeyBuilder.Name names = 1;
- getNamesList() - Method in class io.grpc.lookup.v1.NameMatcher.Builder
-
Ordered list of names (headers or query parameter names) that can supply this value; the first one with a non-empty value is used.
- getNamesList() - Method in class io.grpc.lookup.v1.NameMatcher
-
Ordered list of names (headers or query parameter names) that can supply this value; the first one with a non-empty value is used.
- getNamesList() - Method in interface io.grpc.lookup.v1.NameMatcherOrBuilder
-
Ordered list of names (headers or query parameter names) that can supply this value; the first one with a non-empty value is used.
- getNamesOrBuilder(int) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
-
repeated .grpc.lookup.v1.GrpcKeyBuilder.Name names = 1;
- getNamesOrBuilder(int) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder
-
repeated .grpc.lookup.v1.GrpcKeyBuilder.Name names = 1;
- getNamesOrBuilder(int) - Method in interface io.grpc.lookup.v1.GrpcKeyBuilderOrBuilder
-
repeated .grpc.lookup.v1.GrpcKeyBuilder.Name names = 1;
- getNamesOrBuilderList() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
-
repeated .grpc.lookup.v1.GrpcKeyBuilder.Name names = 1;
- getNamesOrBuilderList() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder
-
repeated .grpc.lookup.v1.GrpcKeyBuilder.Name names = 1;
- getNamesOrBuilderList() - Method in interface io.grpc.lookup.v1.GrpcKeyBuilderOrBuilder
-
repeated .grpc.lookup.v1.GrpcKeyBuilder.Name names = 1;
- getNativeSocketOptions(Channel) - Method in interface io.grpc.netty.InternalNettySocketSupport.InternalHelper
- getNativeSocketOptions(Channel) - Static method in class io.grpc.netty.NettySocketSupport
- getNativeSocketOptions(Channel) - Method in interface io.grpc.netty.NettySocketSupport.Helper
-
Returns the info on the socket if possible.
- getNativeSocketOptions(Channel) - Method in class io.grpc.netty.NettySocketSupport.NettySocketHelperImpl
- getNegotiationLogger() - Method in class io.grpc.netty.GrpcHttp2ConnectionHandler
-
Returns the channel logger for the given channel context.
- getNegotiator() - Method in class io.grpc.netty.NettyChannelCredentials
- getNegotiator() - Method in class io.grpc.netty.NettyServerCredentials
- getNetworkAddressCacheTtlNanos(boolean) - Static method in class io.grpc.internal.DnsNameResolver
-
Returns value of network address cache ttl property if not Android environment.
- getNextId() - Static method in class io.grpc.InternalLogId
- getNonFatalStatusCodesFromHedgingPolicy(Map<String, ?>) - Static method in class io.grpc.internal.ServiceConfigUtil
- getNumber() - Method in enum io.grpc.binarylog.v1.Address.Type
- getNumber() - Method in enum io.grpc.binarylog.v1.GrpcLogEntry.EventType
- getNumber() - Method in enum io.grpc.binarylog.v1.GrpcLogEntry.Logger
- getNumber() - Method in enum io.grpc.binarylog.v1.GrpcLogEntry.PayloadCase
- getNumber() - Method in enum io.grpc.channelz.v1.Address.AddressCase
- getNumber() - Method in enum io.grpc.channelz.v1.ChannelConnectivityState.State
- getNumber() - Method in enum io.grpc.channelz.v1.ChannelTraceEvent.ChildRefCase
- getNumber() - Method in enum io.grpc.channelz.v1.ChannelTraceEvent.Severity
- getNumber() - Method in enum io.grpc.channelz.v1.Security.ModelCase
- getNumber() - Method in enum io.grpc.channelz.v1.Security.Tls.CipherSuiteCase
- getNumber() - Method in enum io.grpc.health.v1.HealthCheckResponse.ServingStatus
- getNumber() - Method in enum io.grpc.lb.v1.LoadBalanceRequest.LoadBalanceRequestTypeCase
- getNumber() - Method in enum io.grpc.lb.v1.LoadBalanceResponse.LoadBalanceResponseTypeCase
- getNumber() - Method in enum io.grpc.lookup.v1.RouteLookupRequest.Reason
- getNumber() - Method in enum io.grpc.reflection.v1.ServerReflectionRequest.MessageRequestCase
- getNumber() - Method in enum io.grpc.reflection.v1.ServerReflectionResponse.MessageResponseCase
- getNumber() - Method in enum io.grpc.reflection.v1alpha.ServerReflectionRequest.MessageRequestCase
- getNumber() - Method in enum io.grpc.reflection.v1alpha.ServerReflectionResponse.MessageResponseCase
- getNumberAsDouble(Map<String, ?>, String) - Static method in class io.grpc.internal.JsonUtil
-
Gets a number from an object for the given key.
- getNumberAsFloat(Map<String, ?>, String) - Static method in class io.grpc.internal.JsonUtil
-
Gets a number from an object for the given key.
- getNumberAsInteger(Map<String, ?>, String) - Static method in class io.grpc.internal.JsonUtil
-
Gets a number from an object for the given key, casted to an integer.
- getNumberAsLong(Map<String, ?>, String) - Static method in class io.grpc.internal.JsonUtil
-
Gets a number from an object for the given key, casted to an long.
- getNumCalls() - Method in class io.grpc.lb.v1.ClientStatsPerToken.Builder
-
The total number of RPCs that finished associated with the token.
- getNumCalls() - Method in class io.grpc.lb.v1.ClientStatsPerToken
-
The total number of RPCs that finished associated with the token.
- getNumCalls() - Method in interface io.grpc.lb.v1.ClientStatsPerTokenOrBuilder
-
The total number of RPCs that finished associated with the token.
- getNumCallsFinished() - Method in class io.grpc.lb.v1.ClientStats.Builder
-
The total number of RPCs that finished.
- getNumCallsFinished() - Method in class io.grpc.lb.v1.ClientStats
-
The total number of RPCs that finished.
- getNumCallsFinished() - Method in interface io.grpc.lb.v1.ClientStatsOrBuilder
-
The total number of RPCs that finished.
- getNumCallsFinishedKnownReceived() - Method in class io.grpc.lb.v1.ClientStats.Builder
-
The total number of RPCs that finished and are known to have been received by a server.
- getNumCallsFinishedKnownReceived() - Method in class io.grpc.lb.v1.ClientStats
-
The total number of RPCs that finished and are known to have been received by a server.
- getNumCallsFinishedKnownReceived() - Method in interface io.grpc.lb.v1.ClientStatsOrBuilder
-
The total number of RPCs that finished and are known to have been received by a server.
- getNumCallsFinishedWithClientFailedToSend() - Method in class io.grpc.lb.v1.ClientStats.Builder
-
The total number of RPCs that failed to reach a server except dropped RPCs.
- getNumCallsFinishedWithClientFailedToSend() - Method in class io.grpc.lb.v1.ClientStats
-
The total number of RPCs that failed to reach a server except dropped RPCs.
- getNumCallsFinishedWithClientFailedToSend() - Method in interface io.grpc.lb.v1.ClientStatsOrBuilder
-
The total number of RPCs that failed to reach a server except dropped RPCs.
- getNumCallsStarted() - Method in class io.grpc.lb.v1.ClientStats.Builder
-
The total number of RPCs that started.
- getNumCallsStarted() - Method in class io.grpc.lb.v1.ClientStats
-
The total number of RPCs that started.
- getNumCallsStarted() - Method in interface io.grpc.lb.v1.ClientStatsOrBuilder
-
The total number of RPCs that started.
- getNumEventsLogged() - Method in class io.grpc.channelz.v1.ChannelTrace.Builder
-
Number of events ever logged in this tracing object.
- getNumEventsLogged() - Method in class io.grpc.channelz.v1.ChannelTrace
-
Number of events ever logged in this tracing object.
- getNumEventsLogged() - Method in interface io.grpc.channelz.v1.ChannelTraceOrBuilder
-
Number of events ever logged in this tracing object.
- 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
- getObject() - Method in class io.grpc.rls.LbPolicyConfiguration.RefCountedChildPolicyWrapper
- getObject(Map<String, ?>, String) - Static method in class io.grpc.internal.JsonUtil
-
Gets an object from an object for the given key.
- getOffloadExecutor() - Method in class io.grpc.NameResolver.Args
-
Returns the Executor on which this resolver should execute long-running or I/O bound work.
- getOffloadExecutorPool() - Method in class io.grpc.internal.ManagedChannelImplBuilder
-
Returns the internal offload executor pool for offloading tasks.
- getOnReadyThreshold() - Method in class io.grpc.CallOptions
-
Returns to the default number of bytes that must be queued before the call will leave the 'wait for ready' state.
- getOption(int) - Method in class io.grpc.channelz.v1.SocketData.Builder
-
Socket options set on this socket.
- getOption(int) - Method in class io.grpc.channelz.v1.SocketData
-
Socket options set on this socket.
- getOption(int) - Method in interface io.grpc.channelz.v1.SocketDataOrBuilder
-
Socket options set on this socket.
- getOption(CallOptions.Key<T>) - Method in class io.grpc.CallOptions
-
Get the value for a custom option or its inherent default.
- getOption(LoadBalancer.CreateSubchannelArgs.Key<T>) - Method in class io.grpc.LoadBalancer.CreateSubchannelArgs
-
Get the value for a custom option or its inherent default.
- getOptionalLabelKeys() - Method in interface io.grpc.MetricInstrument
-
Returns a list of optional label keys for this metric instrument.
- getOptionalLabelKeys() - Method in class io.grpc.PartialMetricInstrument
- getOptionalLabels() - Method in interface io.grpc.MetricSink
-
Returns a set of optional label names for metrics that the sink actually wants.
- getOptionBuilder(int) - Method in class io.grpc.channelz.v1.SocketData.Builder
-
Socket options set on this socket.
- getOptionBuilderList() - Method in class io.grpc.channelz.v1.SocketData.Builder
-
Socket options set on this socket.
- getOptionCount() - Method in class io.grpc.channelz.v1.SocketData.Builder
-
Socket options set on this socket.
- getOptionCount() - Method in class io.grpc.channelz.v1.SocketData
-
Socket options set on this socket.
- getOptionCount() - Method in interface io.grpc.channelz.v1.SocketDataOrBuilder
-
Socket options set on this socket.
- getOptionFieldBuilder() - Method in class io.grpc.channelz.v1.SocketData.Builder
- getOptionList() - Method in class io.grpc.channelz.v1.SocketData.Builder
-
Socket options set on this socket.
- getOptionList() - Method in class io.grpc.channelz.v1.SocketData
-
Socket options set on this socket.
- getOptionList() - Method in interface io.grpc.channelz.v1.SocketDataOrBuilder
-
Socket options set on this socket.
- getOptionOrBuilder(int) - Method in class io.grpc.channelz.v1.SocketData.Builder
-
Socket options set on this socket.
- getOptionOrBuilder(int) - Method in class io.grpc.channelz.v1.SocketData
-
Socket options set on this socket.
- getOptionOrBuilder(int) - Method in interface io.grpc.channelz.v1.SocketDataOrBuilder
-
Socket options set on this socket.
- getOptionOrBuilderList() - Method in class io.grpc.channelz.v1.SocketData.Builder
-
Socket options set on this socket.
- getOptionOrBuilderList() - Method in class io.grpc.channelz.v1.SocketData
-
Socket options set on this socket.
- getOptionOrBuilderList() - Method in interface io.grpc.channelz.v1.SocketDataOrBuilder
-
Socket options set on this socket.
- getOriginalRequest() - Method in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
-
.grpc.reflection.v1.ServerReflectionRequest original_request = 2;
- getOriginalRequest() - Method in class io.grpc.reflection.v1.ServerReflectionResponse
-
.grpc.reflection.v1.ServerReflectionRequest original_request = 2;
- getOriginalRequest() - Method in interface io.grpc.reflection.v1.ServerReflectionResponseOrBuilder
-
.grpc.reflection.v1.ServerReflectionRequest original_request = 2;
- getOriginalRequest() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
-
.grpc.reflection.v1alpha.ServerReflectionRequest original_request = 2;
- getOriginalRequest() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse
-
.grpc.reflection.v1alpha.ServerReflectionRequest original_request = 2;
- getOriginalRequest() - Method in interface io.grpc.reflection.v1alpha.ServerReflectionResponseOrBuilder
-
.grpc.reflection.v1alpha.ServerReflectionRequest original_request = 2;
- getOriginalRequestBuilder() - Method in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
-
.grpc.reflection.v1.ServerReflectionRequest original_request = 2;
- getOriginalRequestBuilder() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
-
.grpc.reflection.v1alpha.ServerReflectionRequest original_request = 2;
- getOriginalRequestFieldBuilder() - Method in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
-
.grpc.reflection.v1.ServerReflectionRequest original_request = 2;
- getOriginalRequestFieldBuilder() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
-
.grpc.reflection.v1alpha.ServerReflectionRequest original_request = 2;
- getOriginalRequestOrBuilder() - Method in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
-
.grpc.reflection.v1.ServerReflectionRequest original_request = 2;
- getOriginalRequestOrBuilder() - Method in class io.grpc.reflection.v1.ServerReflectionResponse
-
.grpc.reflection.v1.ServerReflectionRequest original_request = 2;
- getOriginalRequestOrBuilder() - Method in interface io.grpc.reflection.v1.ServerReflectionResponseOrBuilder
-
.grpc.reflection.v1.ServerReflectionRequest original_request = 2;
- getOriginalRequestOrBuilder() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
-
.grpc.reflection.v1alpha.ServerReflectionRequest original_request = 2;
- getOriginalRequestOrBuilder() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse
-
.grpc.reflection.v1alpha.ServerReflectionRequest original_request = 2;
- getOriginalRequestOrBuilder() - Method in interface io.grpc.reflection.v1alpha.ServerReflectionResponseOrBuilder
-
.grpc.reflection.v1alpha.ServerReflectionRequest original_request = 2;
- getOrUpdateAuthority(AsciiString) - Method in class io.grpc.netty.NettyServerHandler
- getOther() - Method in class io.grpc.channelz.v1.Security.Builder
-
.grpc.channelz.v1.Security.OtherSecurity other = 2;
- getOther() - Method in class io.grpc.channelz.v1.Security
-
.grpc.channelz.v1.Security.OtherSecurity other = 2;
- getOther() - Method in interface io.grpc.channelz.v1.SecurityOrBuilder
-
.grpc.channelz.v1.Security.OtherSecurity other = 2;
- getOtherAddress() - Method in class io.grpc.channelz.v1.Address.Builder
-
.grpc.channelz.v1.Address.OtherAddress other_address = 3;
- getOtherAddress() - Method in class io.grpc.channelz.v1.Address
-
.grpc.channelz.v1.Address.OtherAddress other_address = 3;
- getOtherAddress() - Method in interface io.grpc.channelz.v1.AddressOrBuilder
-
.grpc.channelz.v1.Address.OtherAddress other_address = 3;
- getOtherAddressBuilder() - Method in class io.grpc.channelz.v1.Address.Builder
-
.grpc.channelz.v1.Address.OtherAddress other_address = 3;
- getOtherAddressFieldBuilder() - Method in class io.grpc.channelz.v1.Address.Builder
-
.grpc.channelz.v1.Address.OtherAddress other_address = 3;
- getOtherAddressOrBuilder() - Method in class io.grpc.channelz.v1.Address.Builder
-
.grpc.channelz.v1.Address.OtherAddress other_address = 3;
- getOtherAddressOrBuilder() - Method in class io.grpc.channelz.v1.Address
-
.grpc.channelz.v1.Address.OtherAddress other_address = 3;
- getOtherAddressOrBuilder() - Method in interface io.grpc.channelz.v1.AddressOrBuilder
-
.grpc.channelz.v1.Address.OtherAddress other_address = 3;
- getOtherBuilder() - Method in class io.grpc.channelz.v1.Security.Builder
-
.grpc.channelz.v1.Security.OtherSecurity other = 2;
- getOtherFieldBuilder() - Method in class io.grpc.channelz.v1.Security.Builder
-
.grpc.channelz.v1.Security.OtherSecurity other = 2;
- getOtherName() - Method in class io.grpc.channelz.v1.Security.Tls.Builder
-
Some other way to describe the cipher suite if the RFC 4346 name is not available.
- getOtherName() - Method in class io.grpc.channelz.v1.Security.Tls
-
Some other way to describe the cipher suite if the RFC 4346 name is not available.
- getOtherName() - Method in interface io.grpc.channelz.v1.Security.TlsOrBuilder
-
Some other way to describe the cipher suite if the RFC 4346 name is not available.
- getOtherNameBytes() - Method in class io.grpc.channelz.v1.Security.Tls.Builder
-
Some other way to describe the cipher suite if the RFC 4346 name is not available.
- getOtherNameBytes() - Method in class io.grpc.channelz.v1.Security.Tls
-
Some other way to describe the cipher suite if the RFC 4346 name is not available.
- getOtherNameBytes() - Method in interface io.grpc.channelz.v1.Security.TlsOrBuilder
-
Some other way to describe the cipher suite if the RFC 4346 name is not available.
- getOtherOrBuilder() - Method in class io.grpc.channelz.v1.Security.Builder
-
.grpc.channelz.v1.Security.OtherSecurity other = 2;
- getOtherOrBuilder() - Method in class io.grpc.channelz.v1.Security
-
.grpc.channelz.v1.Security.OtherSecurity other = 2;
- getOtherOrBuilder() - Method in interface io.grpc.channelz.v1.SecurityOrBuilder
-
.grpc.channelz.v1.Security.OtherSecurity other = 2;
- getOverrideAuthority() - Method in class io.grpc.NameResolver.Args
-
Returns the overrideAuthority from channel
ManagedChannelBuilder.overrideAuthority(java.lang.String)
. - getParserForType() - Method in class io.grpc.binarylog.v1.Address
- getParserForType() - Method in class io.grpc.binarylog.v1.ClientHeader
- getParserForType() - Method in class io.grpc.binarylog.v1.GrpcLogEntry
- getParserForType() - Method in class io.grpc.binarylog.v1.Message
- getParserForType() - Method in class io.grpc.binarylog.v1.Metadata
- getParserForType() - Method in class io.grpc.binarylog.v1.MetadataEntry
- getParserForType() - Method in class io.grpc.binarylog.v1.ServerHeader
- getParserForType() - Method in class io.grpc.binarylog.v1.Trailer
- getParserForType() - Method in class io.grpc.channelz.v1.Address
- getParserForType() - Method in class io.grpc.channelz.v1.Address.OtherAddress
- getParserForType() - Method in class io.grpc.channelz.v1.Address.TcpIpAddress
- getParserForType() - Method in class io.grpc.channelz.v1.Address.UdsAddress
- getParserForType() - Method in class io.grpc.channelz.v1.Channel
- getParserForType() - Method in class io.grpc.channelz.v1.ChannelConnectivityState
- getParserForType() - Method in class io.grpc.channelz.v1.ChannelData
- getParserForType() - Method in class io.grpc.channelz.v1.ChannelRef
- getParserForType() - Method in class io.grpc.channelz.v1.ChannelTrace
- getParserForType() - Method in class io.grpc.channelz.v1.ChannelTraceEvent
- getParserForType() - Method in class io.grpc.channelz.v1.GetChannelRequest
- getParserForType() - Method in class io.grpc.channelz.v1.GetChannelResponse
- getParserForType() - Method in class io.grpc.channelz.v1.GetServerRequest
- getParserForType() - Method in class io.grpc.channelz.v1.GetServerResponse
- getParserForType() - Method in class io.grpc.channelz.v1.GetServerSocketsRequest
- getParserForType() - Method in class io.grpc.channelz.v1.GetServerSocketsResponse
- getParserForType() - Method in class io.grpc.channelz.v1.GetServersRequest
- getParserForType() - Method in class io.grpc.channelz.v1.GetServersResponse
- getParserForType() - Method in class io.grpc.channelz.v1.GetSocketRequest
- getParserForType() - Method in class io.grpc.channelz.v1.GetSocketResponse
- getParserForType() - Method in class io.grpc.channelz.v1.GetSubchannelRequest
- getParserForType() - Method in class io.grpc.channelz.v1.GetSubchannelResponse
- getParserForType() - Method in class io.grpc.channelz.v1.GetTopChannelsRequest
- getParserForType() - Method in class io.grpc.channelz.v1.GetTopChannelsResponse
- getParserForType() - Method in class io.grpc.channelz.v1.Security
- getParserForType() - Method in class io.grpc.channelz.v1.Security.OtherSecurity
- getParserForType() - Method in class io.grpc.channelz.v1.Security.Tls
- getParserForType() - Method in class io.grpc.channelz.v1.Server
- getParserForType() - Method in class io.grpc.channelz.v1.ServerData
- getParserForType() - Method in class io.grpc.channelz.v1.ServerRef
- getParserForType() - Method in class io.grpc.channelz.v1.Socket
- getParserForType() - Method in class io.grpc.channelz.v1.SocketData
- getParserForType() - Method in class io.grpc.channelz.v1.SocketOption
- getParserForType() - Method in class io.grpc.channelz.v1.SocketOptionLinger
- getParserForType() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo
- getParserForType() - Method in class io.grpc.channelz.v1.SocketOptionTimeout
- getParserForType() - Method in class io.grpc.channelz.v1.SocketRef
- getParserForType() - Method in class io.grpc.channelz.v1.Subchannel
- getParserForType() - Method in class io.grpc.channelz.v1.SubchannelRef
- getParserForType() - Method in class io.grpc.health.v1.HealthCheckRequest
- getParserForType() - Method in class io.grpc.health.v1.HealthCheckResponse
- getParserForType() - Method in class io.grpc.lb.v1.ClientStats
- getParserForType() - Method in class io.grpc.lb.v1.ClientStatsPerToken
- getParserForType() - Method in class io.grpc.lb.v1.FallbackResponse
- getParserForType() - Method in class io.grpc.lb.v1.InitialLoadBalanceRequest
- getParserForType() - Method in class io.grpc.lb.v1.InitialLoadBalanceResponse
- getParserForType() - Method in class io.grpc.lb.v1.LoadBalanceRequest
- getParserForType() - Method in class io.grpc.lb.v1.LoadBalanceResponse
- getParserForType() - Method in class io.grpc.lb.v1.Server
- getParserForType() - Method in class io.grpc.lb.v1.ServerList
- getParserForType() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys
- getParserForType() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder
- getParserForType() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Name
- getParserForType() - Method in class io.grpc.lookup.v1.HttpKeyBuilder
- getParserForType() - Method in class io.grpc.lookup.v1.NameMatcher
- getParserForType() - Method in class io.grpc.lookup.v1.RouteLookupClusterSpecifier
- getParserForType() - Method in class io.grpc.lookup.v1.RouteLookupConfig
- getParserForType() - Method in class io.grpc.lookup.v1.RouteLookupRequest
- getParserForType() - Method in class io.grpc.lookup.v1.RouteLookupResponse
- getParserForType() - Method in class io.grpc.reflection.v1.ErrorResponse
- getParserForType() - Method in class io.grpc.reflection.v1.ExtensionNumberResponse
- getParserForType() - Method in class io.grpc.reflection.v1.ExtensionRequest
- getParserForType() - Method in class io.grpc.reflection.v1.FileDescriptorResponse
- getParserForType() - Method in class io.grpc.reflection.v1.ListServiceResponse
- getParserForType() - Method in class io.grpc.reflection.v1.ServerReflectionRequest
- getParserForType() - Method in class io.grpc.reflection.v1.ServerReflectionResponse
- getParserForType() - Method in class io.grpc.reflection.v1.ServiceResponse
- getParserForType() - Method in class io.grpc.reflection.v1alpha.ErrorResponse
- getParserForType() - Method in class io.grpc.reflection.v1alpha.ExtensionNumberResponse
- getParserForType() - Method in class io.grpc.reflection.v1alpha.ExtensionRequest
- getParserForType() - Method in class io.grpc.reflection.v1alpha.FileDescriptorResponse
- getParserForType() - Method in class io.grpc.reflection.v1alpha.ListServiceResponse
- getParserForType() - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest
- getParserForType() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse
- getParserForType() - Method in class io.grpc.reflection.v1alpha.ServiceResponse
- getPassword() - Method in class io.grpc.HttpConnectProxiedSocketAddress
-
Returns the password used to connect to the proxy.
- getPath() - Method in class io.grpc.internal.SpiffeUtil.SpiffeId
- getPath() - Method in class io.grpc.protobuf.services.TempFileSink
- getPathPatterns(int) - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
-
path_pattern is an ordered list of path template patterns for the desired value.
- getPathPatterns(int) - Method in class io.grpc.lookup.v1.HttpKeyBuilder
-
path_pattern is an ordered list of path template patterns for the desired value.
- getPathPatterns(int) - Method in interface io.grpc.lookup.v1.HttpKeyBuilderOrBuilder
-
path_pattern is an ordered list of path template patterns for the desired value.
- getPathPatternsBytes(int) - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
-
path_pattern is an ordered list of path template patterns for the desired value.
- getPathPatternsBytes(int) - Method in class io.grpc.lookup.v1.HttpKeyBuilder
-
path_pattern is an ordered list of path template patterns for the desired value.
- getPathPatternsBytes(int) - Method in interface io.grpc.lookup.v1.HttpKeyBuilderOrBuilder
-
path_pattern is an ordered list of path template patterns for the desired value.
- getPathPatternsCount() - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
-
path_pattern is an ordered list of path template patterns for the desired value.
- getPathPatternsCount() - Method in class io.grpc.lookup.v1.HttpKeyBuilder
-
path_pattern is an ordered list of path template patterns for the desired value.
- getPathPatternsCount() - Method in interface io.grpc.lookup.v1.HttpKeyBuilderOrBuilder
-
path_pattern is an ordered list of path template patterns for the desired value.
- getPathPatternsList() - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
-
path_pattern is an ordered list of path template patterns for the desired value.
- getPathPatternsList() - Method in class io.grpc.lookup.v1.HttpKeyBuilder
-
path_pattern is an ordered list of path template patterns for the desired value.
- getPathPatternsList() - Method in interface io.grpc.lookup.v1.HttpKeyBuilderOrBuilder
-
path_pattern is an ordered list of path template patterns for the desired value.
- getPayloadCase() - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
- getPayloadCase() - Method in class io.grpc.binarylog.v1.GrpcLogEntry
- getPayloadCase() - Method in interface io.grpc.binarylog.v1.GrpcLogEntryOrBuilder
- getPayloadTruncated() - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
true if payload does not represent the full message or metadata.
- getPayloadTruncated() - Method in class io.grpc.binarylog.v1.GrpcLogEntry
-
true if payload does not represent the full message or metadata.
- getPayloadTruncated() - Method in interface io.grpc.binarylog.v1.GrpcLogEntryOrBuilder
-
true if payload does not represent the full message or metadata.
- getPeer() - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
Peer address information, will only be recorded on the first incoming event.
- getPeer() - Method in class io.grpc.binarylog.v1.GrpcLogEntry
-
Peer address information, will only be recorded on the first incoming event.
- getPeer() - Method in interface io.grpc.binarylog.v1.GrpcLogEntryOrBuilder
-
Peer address information, will only be recorded on the first incoming event.
- getPeerBuilder() - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
Peer address information, will only be recorded on the first incoming event.
- getPeerFieldBuilder() - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
Peer address information, will only be recorded on the first incoming event.
- getPeerOrBuilder() - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
Peer address information, will only be recorded on the first incoming event.
- getPeerOrBuilder() - Method in class io.grpc.binarylog.v1.GrpcLogEntry
-
Peer address information, will only be recorded on the first incoming event.
- getPeerOrBuilder() - Method in interface io.grpc.binarylog.v1.GrpcLogEntryOrBuilder
-
Peer address information, will only be recorded on the first incoming event.
- getPeerSocket(Attributes) - Static method in class io.grpc.protobuf.services.BinlogHelper
- getPendingStreamsCount() - Method in class io.grpc.internal.DelayedClientTransport
- getPerAttemptRecvTimeoutNanosFromRetryPolicy(Map<String, ?>) - Static method in class io.grpc.internal.ServiceConfigUtil
- getPercentageFromChoice(Map<String, ?>) - Static method in class io.grpc.internal.DnsNameResolver
- getPickDetailsConsumer() - Method in class io.grpc.internal.PickSubchannelArgsImpl
- getPickDetailsConsumer() - Method in class io.grpc.LoadBalancer.PickSubchannelArgs
-
Gets an object that can be informed about what sort of pick was made.
- getPicker() - Method in class io.grpc.rls.LbPolicyConfiguration.ChildPolicyWrapper
- getPingCount() - Method in class io.grpc.netty.AbstractNettyHandler.FlowControlPinger
- getPingReturn() - Method in class io.grpc.netty.AbstractNettyHandler.FlowControlPinger
- getPolicyName() - Method in class io.grpc.grpclb.GrpclbLoadBalancerProvider
- getPolicyName() - Method in class io.grpc.internal.PickFirstLoadBalancerProvider
- getPolicyName() - Method in class io.grpc.internal.ServiceConfigUtil.LbConfig
- getPolicyName() - Method in class io.grpc.LoadBalancerProvider
-
Returns the load-balancing policy name associated with this provider, which makes it selectable via
LoadBalancerRegistry.getProvider(java.lang.String)
. - getPolicyName() - Method in class io.grpc.protobuf.services.internal.HealthCheckingRoundRobinLoadBalancerProvider
- getPolicyName() - Method in class io.grpc.rls.RlsLoadBalancerProvider
- getPolicyName() - Method in class io.grpc.util.OutlierDetectionLoadBalancerProvider
- getPolicyName() - Method in class io.grpc.util.SecretRoundRobinLoadBalancerProvider.Provider
- getPort() - Method in class io.grpc.channelz.v1.Address.TcpIpAddress.Builder
-
0-64k, or -1 if not appropriate.
- getPort() - Method in class io.grpc.channelz.v1.Address.TcpIpAddress
-
0-64k, or -1 if not appropriate.
- getPort() - Method in interface io.grpc.channelz.v1.Address.TcpIpAddressOrBuilder
-
0-64k, or -1 if not appropriate.
- getPort() - Method in class io.grpc.internal.DnsNameResolver
- getPort() - Method in class io.grpc.internal.ServerImpl
- getPort() - Method in class io.grpc.lb.v1.Server.Builder
-
A resolved port number for the server.
- getPort() - Method in class io.grpc.lb.v1.Server
-
A resolved port number for the server.
- getPort() - Method in interface io.grpc.lb.v1.ServerOrBuilder
-
A resolved port number for the server.
- getPort() - Method in class io.grpc.Server
-
Returns the port number the server is listening on.
- getPreviousAttempts() - Method in class io.grpc.ClientStreamTracer.StreamInfo
-
Returns the number of preceding attempts for the RPC.
- getPriority() - Method in class io.grpc.grpclb.GrpclbLoadBalancerProvider
- getPriority() - Method in class io.grpc.internal.PickFirstLoadBalancerProvider
- getPriority() - Method in class io.grpc.LoadBalancerProvider
-
A priority, from 0 to 10 that this provider should be used, taking the current environment into consideration.
- getPriority() - Method in class io.grpc.protobuf.services.internal.HealthCheckingRoundRobinLoadBalancerProvider
- getPriority() - Method in class io.grpc.rls.RlsLoadBalancerProvider
- getPriority() - Method in class io.grpc.util.OutlierDetectionLoadBalancerProvider
- getPriority() - Method in class io.grpc.util.SecretRoundRobinLoadBalancerProvider.Provider
- getPriority(LoadBalancerProvider) - Method in class io.grpc.LoadBalancerRegistry.LoadBalancerPriorityAccessor
- getPriority(ManagedChannelProvider) - Method in class io.grpc.ManagedChannelRegistry.ManagedChannelPriorityAccessor
- getPriority(NameResolverProvider) - Method in class io.grpc.NameResolverRegistry.NameResolverPriorityAccessor
- getPriority(ServerProvider) - Method in class io.grpc.ServerRegistry.ServerPriorityAccessor
- getPriority(T) - Method in interface io.grpc.ServiceProviders.PriorityAccessor
-
A priority, from 0 to 10 that this provider should be used, taking the current environment into consideration.
- getPrivateKey() - Method in class io.grpc.TlsChannelCredentials
-
The private key for the client's identity, as a new byte array.
- getPrivateKey() - Method in class io.grpc.TlsServerCredentials
-
The private key for the server's identity, as a new byte array.
- getPrivateKey(InputStream) - Static method in class io.grpc.util.CertificateUtils
-
Generates a
PrivateKey
from a PEM file. - getPrivateKey(String) - Method in class io.grpc.util.AdvancedTlsX509KeyManager
- getPrivateKeyPassword() - Method in class io.grpc.TlsChannelCredentials
-
Returns the password to decrypt the private key, or
null
if unencrypted. - getPrivateKeyPassword() - Method in class io.grpc.TlsServerCredentials
-
Returns the password to decrypt the private key, or
null
if unencrypted. - getProducedSocketAddressTypes() - Method in class io.grpc.grpclb.SecretGrpclbNameResolverProvider.Provider
- getProducedSocketAddressTypes() - Method in class io.grpc.internal.DnsNameResolverProvider
- getProducedSocketAddressTypes() - Method in class io.grpc.internal.ManagedChannelImplBuilder.DirectAddressNameResolverProvider
- getProducedSocketAddressTypes() - Method in class io.grpc.NameResolverProvider
-
Returns the
SocketAddress
types this provider's name-resolver is capable of producing. - getProducedSocketAddressTypes() - Method in class io.grpc.netty.UdsNameResolverProvider
- getProtocolNegotiationEvent() - Method in class io.grpc.netty.ProtocolNegotiators.ProtocolNegotiationHandler
- getProvider() - Method in class io.grpc.internal.ServiceConfigUtil.PolicySelection
- getProvider(String) - Method in class io.grpc.LoadBalancerRegistry
-
Returns the effective provider for the given load-balancing policy, or
null
if no suitable provider can be found. - getProviderForScheme(String) - Method in class io.grpc.NameResolverRegistry
- getProviderOrThrow(String, String) - Method in class io.grpc.internal.AutoConfiguredLoadBalancerFactory
- getProxyAddress() - Method in class io.grpc.HttpConnectProxiedSocketAddress
-
Returns the address to the proxy, which is already resolved.
- getProxyDetector() - Method in class io.grpc.NameResolver.Args
-
If the NameResolver wants to support proxy, it should inquire this
ProxyDetector
. - getPseudoHeader(AsciiString) - Method in class io.grpc.netty.GrpcHttp2HeadersUtils.GrpcHttp2RequestHeaders
- getPushbackMills(Metadata) - Method in class io.grpc.internal.RetriableStream.Sublistener
- getQps() - Method in class io.grpc.services.MetricReport
- getQueryParameters(int) - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
-
List of query parameter names to try to match.
- getQueryParameters(int) - Method in class io.grpc.lookup.v1.HttpKeyBuilder
-
List of query parameter names to try to match.
- getQueryParameters(int) - Method in interface io.grpc.lookup.v1.HttpKeyBuilderOrBuilder
-
List of query parameter names to try to match.
- getQueryParametersBuilder(int) - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
-
List of query parameter names to try to match.
- getQueryParametersBuilderList() - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
-
List of query parameter names to try to match.
- getQueryParametersCount() - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
-
List of query parameter names to try to match.
- getQueryParametersCount() - Method in class io.grpc.lookup.v1.HttpKeyBuilder
-
List of query parameter names to try to match.
- getQueryParametersCount() - Method in interface io.grpc.lookup.v1.HttpKeyBuilderOrBuilder
-
List of query parameter names to try to match.
- getQueryParametersFieldBuilder() - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
- getQueryParametersList() - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
-
List of query parameter names to try to match.
- getQueryParametersList() - Method in class io.grpc.lookup.v1.HttpKeyBuilder
-
List of query parameter names to try to match.
- getQueryParametersList() - Method in interface io.grpc.lookup.v1.HttpKeyBuilderOrBuilder
-
List of query parameter names to try to match.
- getQueryParametersOrBuilder(int) - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
-
List of query parameter names to try to match.
- getQueryParametersOrBuilder(int) - Method in class io.grpc.lookup.v1.HttpKeyBuilder
-
List of query parameter names to try to match.
- getQueryParametersOrBuilder(int) - Method in interface io.grpc.lookup.v1.HttpKeyBuilderOrBuilder
-
List of query parameter names to try to match.
- getQueryParametersOrBuilderList() - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
-
List of query parameter names to try to match.
- getQueryParametersOrBuilderList() - Method in class io.grpc.lookup.v1.HttpKeyBuilder
-
List of query parameter names to try to match.
- getQueryParametersOrBuilderList() - Method in interface io.grpc.lookup.v1.HttpKeyBuilderOrBuilder
-
List of query parameter names to try to match.
- getRawAdvertisedMessageEncodings() - Method in class io.grpc.DecompressorRegistry
- getRawAdvertisedMessageEncodings(DecompressorRegistry) - Static method in class io.grpc.InternalDecompressorRegistry
- getRawConfigValue() - Method in class io.grpc.internal.ServiceConfigUtil.LbConfig
- getRawMethodName(int) - Method in class io.grpc.MethodDescriptor
-
Gets the cached "raw" method name for this Method Descriptor.
- getReadyChildren() - Method in class io.grpc.util.MultiChildLoadBalancer
-
Filters out non-ready child load balancers (subchannels).
- getRealCall() - Method in class io.grpc.internal.DelayedClientCall
- getRealStream() - Method in class io.grpc.internal.DelayedStream
- getReason() - Method in class io.grpc.lookup.v1.RouteLookupRequest.Builder
-
Reason for making this request.
- getReason() - Method in class io.grpc.lookup.v1.RouteLookupRequest
-
Reason for making this request.
- getReason() - Method in interface io.grpc.lookup.v1.RouteLookupRequestOrBuilder
-
Reason for making this request.
- getReasonValue() - Method in class io.grpc.lookup.v1.RouteLookupRequest.Builder
-
Reason for making this request.
- getReasonValue() - Method in class io.grpc.lookup.v1.RouteLookupRequest
-
Reason for making this request.
- getReasonValue() - Method in interface io.grpc.lookup.v1.RouteLookupRequestOrBuilder
-
Reason for making this request.
- getRef() - Method in class io.grpc.channelz.v1.Channel.Builder
-
The identifier for this channel.
- getRef() - Method in class io.grpc.channelz.v1.Channel
-
The identifier for this channel.
- getRef() - Method in interface io.grpc.channelz.v1.ChannelOrBuilder
-
The identifier for this channel.
- getRef() - Method in class io.grpc.channelz.v1.Server.Builder
-
The identifier for a Server.
- getRef() - Method in class io.grpc.channelz.v1.Server
-
The identifier for a Server.
- getRef() - Method in interface io.grpc.channelz.v1.ServerOrBuilder
-
The identifier for a Server.
- getRef() - Method in class io.grpc.channelz.v1.Socket.Builder
-
The identifier for the Socket.
- getRef() - Method in class io.grpc.channelz.v1.Socket
-
The identifier for the Socket.
- getRef() - Method in interface io.grpc.channelz.v1.SocketOrBuilder
-
The identifier for the Socket.
- getRef() - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
The identifier for this channel.
- getRef() - Method in class io.grpc.channelz.v1.Subchannel
-
The identifier for this channel.
- getRef() - Method in interface io.grpc.channelz.v1.SubchannelOrBuilder
-
The identifier for this channel.
- getRefBuilder() - Method in class io.grpc.channelz.v1.Channel.Builder
-
The identifier for this channel.
- getRefBuilder() - Method in class io.grpc.channelz.v1.Server.Builder
-
The identifier for a Server.
- getRefBuilder() - Method in class io.grpc.channelz.v1.Socket.Builder
-
The identifier for the Socket.
- getRefBuilder() - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
The identifier for this channel.
- getRefFieldBuilder() - Method in class io.grpc.channelz.v1.Channel.Builder
-
The identifier for this channel.
- getRefFieldBuilder() - Method in class io.grpc.channelz.v1.Server.Builder
-
The identifier for a Server.
- getRefFieldBuilder() - Method in class io.grpc.channelz.v1.Socket.Builder
-
The identifier for the Socket.
- getRefFieldBuilder() - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
The identifier for this channel.
- getRefOrBuilder() - Method in class io.grpc.channelz.v1.Channel.Builder
-
The identifier for this channel.
- getRefOrBuilder() - Method in class io.grpc.channelz.v1.Channel
-
The identifier for this channel.
- getRefOrBuilder() - Method in interface io.grpc.channelz.v1.ChannelOrBuilder
-
The identifier for this channel.
- getRefOrBuilder() - Method in class io.grpc.channelz.v1.Server.Builder
-
The identifier for a Server.
- getRefOrBuilder() - Method in class io.grpc.channelz.v1.Server
-
The identifier for a Server.
- getRefOrBuilder() - Method in interface io.grpc.channelz.v1.ServerOrBuilder
-
The identifier for a Server.
- getRefOrBuilder() - Method in class io.grpc.channelz.v1.Socket.Builder
-
The identifier for the Socket.
- getRefOrBuilder() - Method in class io.grpc.channelz.v1.Socket
-
The identifier for the Socket.
- getRefOrBuilder() - Method in interface io.grpc.channelz.v1.SocketOrBuilder
-
The identifier for the Socket.
- getRefOrBuilder() - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
The identifier for this channel.
- getRefOrBuilder() - Method in class io.grpc.channelz.v1.Subchannel
-
The identifier for this channel.
- getRefOrBuilder() - Method in interface io.grpc.channelz.v1.SubchannelOrBuilder
-
The identifier for this channel.
- getRefreshedIndex() - Method in class io.grpc.protobuf.services.ProtoReflectionServiceV1
-
Retrieves the index for services of the server that dispatches the current call.
- getRemote() - Method in class io.grpc.channelz.v1.Socket.Builder
-
The remote bound address.
- getRemote() - Method in class io.grpc.channelz.v1.Socket
-
The remote bound address.
- getRemote() - Method in interface io.grpc.channelz.v1.SocketOrBuilder
-
The remote bound address.
- getRemoteBuilder() - Method in class io.grpc.channelz.v1.Socket.Builder
-
The remote bound address.
- getRemoteCertificate() - Method in class io.grpc.channelz.v1.Security.Tls.Builder
-
the certificate used by the remote endpoint.
- getRemoteCertificate() - Method in class io.grpc.channelz.v1.Security.Tls
-
the certificate used by the remote endpoint.
- getRemoteCertificate() - Method in interface io.grpc.channelz.v1.Security.TlsOrBuilder
-
the certificate used by the remote endpoint.
- getRemoteFieldBuilder() - Method in class io.grpc.channelz.v1.Socket.Builder
-
The remote bound address.
- getRemoteFlowControlWindow() - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The amount of window, granted to the remote endpoint by the local endpoint.
- getRemoteFlowControlWindow() - Method in class io.grpc.channelz.v1.SocketData
-
The amount of window, granted to the remote endpoint by the local endpoint.
- getRemoteFlowControlWindow() - Method in interface io.grpc.channelz.v1.SocketDataOrBuilder
-
The amount of window, granted to the remote endpoint by the local endpoint.
- getRemoteFlowControlWindowBuilder() - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The amount of window, granted to the remote endpoint by the local endpoint.
- getRemoteFlowControlWindowFieldBuilder() - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The amount of window, granted to the remote endpoint by the local endpoint.
- getRemoteFlowControlWindowOrBuilder() - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The amount of window, granted to the remote endpoint by the local endpoint.
- getRemoteFlowControlWindowOrBuilder() - Method in class io.grpc.channelz.v1.SocketData
-
The amount of window, granted to the remote endpoint by the local endpoint.
- getRemoteFlowControlWindowOrBuilder() - Method in interface io.grpc.channelz.v1.SocketDataOrBuilder
-
The amount of window, granted to the remote endpoint by the local endpoint.
- getRemoteName() - Method in class io.grpc.channelz.v1.Socket.Builder
-
Optional, represents the name of the remote endpoint, if different than the original target name.
- getRemoteName() - Method in class io.grpc.channelz.v1.Socket
-
Optional, represents the name of the remote endpoint, if different than the original target name.
- getRemoteName() - Method in interface io.grpc.channelz.v1.SocketOrBuilder
-
Optional, represents the name of the remote endpoint, if different than the original target name.
- getRemoteNameBytes() - Method in class io.grpc.channelz.v1.Socket.Builder
-
Optional, represents the name of the remote endpoint, if different than the original target name.
- getRemoteNameBytes() - Method in class io.grpc.channelz.v1.Socket
-
Optional, represents the name of the remote endpoint, if different than the original target name.
- getRemoteNameBytes() - Method in interface io.grpc.channelz.v1.SocketOrBuilder
-
Optional, represents the name of the remote endpoint, if different than the original target name.
- getRemoteOrBuilder() - Method in class io.grpc.channelz.v1.Socket.Builder
-
The remote bound address.
- getRemoteOrBuilder() - Method in class io.grpc.channelz.v1.Socket
-
The remote bound address.
- getRemoteOrBuilder() - Method in interface io.grpc.channelz.v1.SocketOrBuilder
-
The remote bound address.
- getRequestCostMetrics() - Method in class io.grpc.services.MetricReport
- getRequestMarshaller() - Method in class io.grpc.MethodDescriptor
-
Returns the marshaller for the request type.
- getRequiredLabelKeys() - Method in interface io.grpc.MetricInstrument
-
Returns a list of required label keys for this metric instrument.
- getRequiredLabelKeys() - Method in class io.grpc.PartialMetricInstrument
- getRequiredMatch() - Method in class io.grpc.lookup.v1.NameMatcher.Builder
-
If true, make this extraction required; the key builder will not match if no value is found.
- getRequiredMatch() - Method in class io.grpc.lookup.v1.NameMatcher
-
If true, make this extraction required; the key builder will not match if no value is found.
- getRequiredMatch() - Method in interface io.grpc.lookup.v1.NameMatcherOrBuilder
-
If true, make this extraction required; the key builder will not match if no value is found.
- getResolvedAddresses() - Method in class io.grpc.util.MultiChildLoadBalancer.ChildLbState
- getResourceResolver() - Method in class io.grpc.internal.DnsNameResolver
- getResourceResolverFactory(ClassLoader) - Static method in class io.grpc.internal.DnsNameResolver
- getResponseForWatch(HealthCheckResponse.ServingStatus) - Static method in class io.grpc.protobuf.services.HealthServiceImpl
- getResponseMarshaller() - Method in class io.grpc.MethodDescriptor
-
Returns the marshaller for the response type.
- getRetriedNameResolver() - Method in class io.grpc.internal.RetryingNameResolver
-
Used to get the underlying
NameResolver
that is getting its failed attempts retried. - getRetryableStatusCodesFromRetryPolicy(Map<String, ?>) - Static method in class io.grpc.internal.ServiceConfigUtil
- getRetryPolicyFromMethodConfig(Map<String, ?>) - Static method in class io.grpc.internal.ServiceConfigUtil
- getRetryThrottling() - Method in class io.grpc.internal.ManagedChannelServiceConfig
- getRootCertificates() - Method in class io.grpc.TlsChannelCredentials
-
Root trust certificates for verifying the server's identity that override the system's defaults.
- getRootCertificates() - Method in class io.grpc.TlsServerCredentials
-
Root trust certificates for verifying the client's identity that override the system's defaults.
- getRootChannel(long) - Method in class io.grpc.InternalChannelz
- getRootChannels(long, int) - Method in class io.grpc.InternalChannelz
-
Returns a
InternalChannelz.RootChannelList
. - getRouteLookupChannelServiceConfig() - Method in class io.grpc.rls.LbPolicyConfiguration
- getRouteLookupConfig() - Method in class io.grpc.lookup.v1.RouteLookupClusterSpecifier.Builder
-
The RLS config for this cluster specifier plugin instance.
- getRouteLookupConfig() - Method in class io.grpc.lookup.v1.RouteLookupClusterSpecifier
-
The RLS config for this cluster specifier plugin instance.
- getRouteLookupConfig() - Method in interface io.grpc.lookup.v1.RouteLookupClusterSpecifierOrBuilder
-
The RLS config for this cluster specifier plugin instance.
- getRouteLookupConfig() - Method in class io.grpc.rls.LbPolicyConfiguration
- getRouteLookupConfigBuilder() - Method in class io.grpc.lookup.v1.RouteLookupClusterSpecifier.Builder
-
The RLS config for this cluster specifier plugin instance.
- getRouteLookupConfigFieldBuilder() - Method in class io.grpc.lookup.v1.RouteLookupClusterSpecifier.Builder
-
The RLS config for this cluster specifier plugin instance.
- getRouteLookupConfigOrBuilder() - Method in class io.grpc.lookup.v1.RouteLookupClusterSpecifier.Builder
-
The RLS config for this cluster specifier plugin instance.
- getRouteLookupConfigOrBuilder() - Method in class io.grpc.lookup.v1.RouteLookupClusterSpecifier
-
The RLS config for this cluster specifier plugin instance.
- getRouteLookupConfigOrBuilder() - Method in interface io.grpc.lookup.v1.RouteLookupClusterSpecifierOrBuilder
-
The RLS config for this cluster specifier plugin instance.
- getRouteLookupMethod - Static variable in class io.grpc.lookup.v1.RouteLookupServiceGrpc
- getRouteLookupMethod() - Static method in class io.grpc.lookup.v1.RouteLookupServiceGrpc
- getScheduledExecutorService() - Method in class io.grpc.inprocess.InProcessChannelBuilder.InProcessClientTransportFactory
- getScheduledExecutorService() - Method in class io.grpc.inprocess.InProcessTransport
- getScheduledExecutorService() - Method in class io.grpc.internal.CallCredentialsApplyingTransportFactory
- getScheduledExecutorService() - Method in interface io.grpc.internal.ClientTransportFactory
-
Returns an executor for scheduling provided by the transport.
- getScheduledExecutorService() - Method in class io.grpc.internal.ManagedChannelImpl.LbHelperImpl
- getScheduledExecutorService() - Method in interface io.grpc.internal.ServerTransport
-
Returns an executor for scheduling provided by the transport.
- getScheduledExecutorService() - Method in class io.grpc.LoadBalancer.Helper
-
Returns a
ScheduledExecutorService
for scheduling delayed tasks. - getScheduledExecutorService() - Method in class io.grpc.NameResolver.Args
-
Returns a
ScheduledExecutorService
for scheduling delayed tasks. - getScheduledExecutorService() - Method in class io.grpc.netty.NettyChannelBuilder.NettyTransportFactory
- getScheduledExecutorService() - Method in class io.grpc.netty.NettyServerTransport
- getScheduledExecutorService() - Method in class io.grpc.servlet.jakarta.ServletServerBuilder.ServerTransportImpl
- getScheduledExecutorService() - Method in class io.grpc.servlet.ServletServerBuilder.ServerTransportImpl
- getScheduledExecutorService() - Method in class io.grpc.util.ForwardingLoadBalancerHelper
- getScheduledExecutorServicePool() - Method in class io.grpc.inprocess.InProcessServer
- 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.
- getScheme() - Method in class io.grpc.NameResolverProvider
-
Returns the scheme associated with the provider.
- getSecurity() - Method in class io.grpc.channelz.v1.Socket.Builder
-
Security details for this socket.
- getSecurity() - Method in class io.grpc.channelz.v1.Socket
-
Security details for this socket.
- getSecurity() - Method in interface io.grpc.channelz.v1.SocketOrBuilder
-
Security details for this socket.
- getSecurity() - Method in class io.grpc.netty.ProtocolNegotiationEvent
- getSecurity(ProtocolNegotiationEvent) - Static method in class io.grpc.netty.InternalProtocolNegotiationEvent
- getSecurityBuilder() - Method in class io.grpc.channelz.v1.Socket.Builder
-
Security details for this socket.
- getSecurityFieldBuilder() - Method in class io.grpc.channelz.v1.Socket.Builder
-
Security details for this socket.
- getSecurityInfo() - Method in class io.grpc.netty.NettyClientHandler
- getSecurityInfo() - Method in class io.grpc.netty.NettyServerHandler
- getSecurityLevel() - Method in class io.grpc.CallCredentials.RequestInfo
-
The security level on the transport.
- getSecurityLevel() - Method in class io.grpc.internal.ServerCallImpl
- getSecurityLevel() - Method in class io.grpc.PartialForwardingServerCall
- getSecurityLevel() - Method in class io.grpc.ServerCall
-
Returns the level of security guarantee in communications
- getSecurityOrBuilder() - Method in class io.grpc.channelz.v1.Socket.Builder
-
Security details for this socket.
- getSecurityOrBuilder() - Method in class io.grpc.channelz.v1.Socket
-
Security details for this socket.
- getSecurityOrBuilder() - Method in interface io.grpc.channelz.v1.SocketOrBuilder
-
Security details for this socket.
- getSequenceIdWithinCall() - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
The entry sequence id for this call.
- getSequenceIdWithinCall() - Method in class io.grpc.binarylog.v1.GrpcLogEntry
-
The entry sequence id for this call.
- getSequenceIdWithinCall() - Method in interface io.grpc.binarylog.v1.GrpcLogEntryOrBuilder
-
The entry sequence id for this call.
- getSequenceNumbers() - Method in class io.grpc.internal.SpiffeUtil.SpiffeBundle
- getSerializedSize() - Method in class io.grpc.binarylog.v1.Address
- getSerializedSize() - Method in class io.grpc.binarylog.v1.ClientHeader
- getSerializedSize() - Method in class io.grpc.binarylog.v1.GrpcLogEntry
- getSerializedSize() - Method in class io.grpc.binarylog.v1.Message
- getSerializedSize() - Method in class io.grpc.binarylog.v1.Metadata
- getSerializedSize() - Method in class io.grpc.binarylog.v1.MetadataEntry
- getSerializedSize() - Method in class io.grpc.binarylog.v1.ServerHeader
- getSerializedSize() - Method in class io.grpc.binarylog.v1.Trailer
- getSerializedSize() - Method in class io.grpc.channelz.v1.Address
- getSerializedSize() - Method in class io.grpc.channelz.v1.Address.OtherAddress
- getSerializedSize() - Method in class io.grpc.channelz.v1.Address.TcpIpAddress
- getSerializedSize() - Method in class io.grpc.channelz.v1.Address.UdsAddress
- getSerializedSize() - Method in class io.grpc.channelz.v1.Channel
- getSerializedSize() - Method in class io.grpc.channelz.v1.ChannelConnectivityState
- getSerializedSize() - Method in class io.grpc.channelz.v1.ChannelData
- getSerializedSize() - Method in class io.grpc.channelz.v1.ChannelRef
- getSerializedSize() - Method in class io.grpc.channelz.v1.ChannelTrace
- getSerializedSize() - Method in class io.grpc.channelz.v1.ChannelTraceEvent
- getSerializedSize() - Method in class io.grpc.channelz.v1.GetChannelRequest
- getSerializedSize() - Method in class io.grpc.channelz.v1.GetChannelResponse
- getSerializedSize() - Method in class io.grpc.channelz.v1.GetServerRequest
- getSerializedSize() - Method in class io.grpc.channelz.v1.GetServerResponse
- getSerializedSize() - Method in class io.grpc.channelz.v1.GetServerSocketsRequest
- getSerializedSize() - Method in class io.grpc.channelz.v1.GetServerSocketsResponse
- getSerializedSize() - Method in class io.grpc.channelz.v1.GetServersRequest
- getSerializedSize() - Method in class io.grpc.channelz.v1.GetServersResponse
- getSerializedSize() - Method in class io.grpc.channelz.v1.GetSocketRequest
- getSerializedSize() - Method in class io.grpc.channelz.v1.GetSocketResponse
- getSerializedSize() - Method in class io.grpc.channelz.v1.GetSubchannelRequest
- getSerializedSize() - Method in class io.grpc.channelz.v1.GetSubchannelResponse
- getSerializedSize() - Method in class io.grpc.channelz.v1.GetTopChannelsRequest
- getSerializedSize() - Method in class io.grpc.channelz.v1.GetTopChannelsResponse
- getSerializedSize() - Method in class io.grpc.channelz.v1.Security
- getSerializedSize() - Method in class io.grpc.channelz.v1.Security.OtherSecurity
- getSerializedSize() - Method in class io.grpc.channelz.v1.Security.Tls
- getSerializedSize() - Method in class io.grpc.channelz.v1.Server
- getSerializedSize() - Method in class io.grpc.channelz.v1.ServerData
- getSerializedSize() - Method in class io.grpc.channelz.v1.ServerRef
- getSerializedSize() - Method in class io.grpc.channelz.v1.Socket
- getSerializedSize() - Method in class io.grpc.channelz.v1.SocketData
- getSerializedSize() - Method in class io.grpc.channelz.v1.SocketOption
- getSerializedSize() - Method in class io.grpc.channelz.v1.SocketOptionLinger
- getSerializedSize() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo
- getSerializedSize() - Method in class io.grpc.channelz.v1.SocketOptionTimeout
- getSerializedSize() - Method in class io.grpc.channelz.v1.SocketRef
- getSerializedSize() - Method in class io.grpc.channelz.v1.Subchannel
- getSerializedSize() - Method in class io.grpc.channelz.v1.SubchannelRef
- getSerializedSize() - Method in class io.grpc.health.v1.HealthCheckRequest
- getSerializedSize() - Method in class io.grpc.health.v1.HealthCheckResponse
- getSerializedSize() - Method in class io.grpc.lb.v1.ClientStats
- getSerializedSize() - Method in class io.grpc.lb.v1.ClientStatsPerToken
- getSerializedSize() - Method in class io.grpc.lb.v1.FallbackResponse
- getSerializedSize() - Method in class io.grpc.lb.v1.InitialLoadBalanceRequest
- getSerializedSize() - Method in class io.grpc.lb.v1.InitialLoadBalanceResponse
- getSerializedSize() - Method in class io.grpc.lb.v1.LoadBalanceRequest
- getSerializedSize() - Method in class io.grpc.lb.v1.LoadBalanceResponse
- getSerializedSize() - Method in class io.grpc.lb.v1.Server
- getSerializedSize() - Method in class io.grpc.lb.v1.ServerList
- getSerializedSize() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys
- getSerializedSize() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder
- getSerializedSize() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Name
- getSerializedSize() - Method in class io.grpc.lookup.v1.HttpKeyBuilder
- getSerializedSize() - Method in class io.grpc.lookup.v1.NameMatcher
- getSerializedSize() - Method in class io.grpc.lookup.v1.RouteLookupClusterSpecifier
- getSerializedSize() - Method in class io.grpc.lookup.v1.RouteLookupConfig
- getSerializedSize() - Method in class io.grpc.lookup.v1.RouteLookupRequest
- getSerializedSize() - Method in class io.grpc.lookup.v1.RouteLookupResponse
- getSerializedSize() - Method in class io.grpc.reflection.v1.ErrorResponse
- getSerializedSize() - Method in class io.grpc.reflection.v1.ExtensionNumberResponse
- getSerializedSize() - Method in class io.grpc.reflection.v1.ExtensionRequest
- getSerializedSize() - Method in class io.grpc.reflection.v1.FileDescriptorResponse
- getSerializedSize() - Method in class io.grpc.reflection.v1.ListServiceResponse
- getSerializedSize() - Method in class io.grpc.reflection.v1.ServerReflectionRequest
- getSerializedSize() - Method in class io.grpc.reflection.v1.ServerReflectionResponse
- getSerializedSize() - Method in class io.grpc.reflection.v1.ServiceResponse
- getSerializedSize() - Method in class io.grpc.reflection.v1alpha.ErrorResponse
- getSerializedSize() - Method in class io.grpc.reflection.v1alpha.ExtensionNumberResponse
- getSerializedSize() - Method in class io.grpc.reflection.v1alpha.ExtensionRequest
- getSerializedSize() - Method in class io.grpc.reflection.v1alpha.FileDescriptorResponse
- getSerializedSize() - Method in class io.grpc.reflection.v1alpha.ListServiceResponse
- getSerializedSize() - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest
- getSerializedSize() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse
- getSerializedSize() - Method in class io.grpc.reflection.v1alpha.ServiceResponse
- getServer() - Method in class io.grpc.channelz.v1.GetServerResponse.Builder
-
The Server that corresponds to the requested server_id.
- getServer() - Method in class io.grpc.channelz.v1.GetServerResponse
-
The Server that corresponds to the requested server_id.
- getServer() - Method in interface io.grpc.channelz.v1.GetServerResponseOrBuilder
-
The Server that corresponds to the requested server_id.
- getServer() - Method in class io.grpc.inprocess.AnonymousInProcessSocketAddress
- getServer(int) - Method in class io.grpc.channelz.v1.GetServersResponse.Builder
-
list of servers that the connection detail service knows about.
- getServer(int) - Method in class io.grpc.channelz.v1.GetServersResponse
-
list of servers that the connection detail service knows about.
- getServer(int) - Method in interface io.grpc.channelz.v1.GetServersResponseOrBuilder
-
list of servers that the connection detail service knows about.
- getServer(long) - Method in class io.grpc.InternalChannelz
-
Returns a server.
- getServer(GetServerRequest) - Method in class io.grpc.channelz.v1.ChannelzGrpc.ChannelzBlockingStub
-
Returns a single Server, or else a NOT_FOUND code.
- getServer(GetServerRequest) - Method in class io.grpc.channelz.v1.ChannelzGrpc.ChannelzFutureStub
-
Returns a single Server, or else a NOT_FOUND code.
- getServer(GetServerRequest, StreamObserver<GetServerResponse>) - Method in interface io.grpc.channelz.v1.ChannelzGrpc.AsyncService
-
Returns a single Server, or else a NOT_FOUND code.
- getServer(GetServerRequest, StreamObserver<GetServerResponse>) - Method in class io.grpc.channelz.v1.ChannelzGrpc.ChannelzStub
-
Returns a single Server, or else a NOT_FOUND code.
- getServer(GetServerRequest, StreamObserver<GetServerResponse>) - Method in class io.grpc.protobuf.services.ChannelzService
-
Returns a server.
- getServer(GetServerRequest, StreamObserver<GetServerResponse>) - Method in class io.grpc.services.ChannelzService
-
Deprecated.Returns a server.
- getServerAliases(String, Principal[]) - Method in class io.grpc.util.AdvancedTlsX509KeyManager
- getServerBuilder() - Method in class io.grpc.channelz.v1.GetServerResponse.Builder
-
The Server that corresponds to the requested server_id.
- getServerBuilder() - Method in class io.grpc.ServerProvider.NewServerBuilderResult
- getServerBuilder(int) - Method in class io.grpc.channelz.v1.GetServersResponse.Builder
-
list of servers that the connection detail service knows about.
- getServerBuilderList() - Method in class io.grpc.channelz.v1.GetServersResponse.Builder
-
list of servers that the connection detail service knows about.
- getServerCallHandler() - Method in class io.grpc.ServerMethodDefinition
-
Handler for incoming calls.
- getServerCount() - Method in class io.grpc.channelz.v1.GetServersResponse.Builder
-
list of servers that the connection detail service knows about.
- getServerCount() - Method in class io.grpc.channelz.v1.GetServersResponse
-
list of servers that the connection detail service knows about.
- getServerCount() - Method in interface io.grpc.channelz.v1.GetServersResponseOrBuilder
-
list of servers that the connection detail service knows about.
- getServerFieldBuilder() - Method in class io.grpc.channelz.v1.GetServerResponse.Builder
-
The Server that corresponds to the requested server_id.
- getServerFieldBuilder() - Method in class io.grpc.channelz.v1.GetServersResponse.Builder
- getServerHeader() - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
.grpc.binarylog.v1.ServerHeader server_header = 7;
- getServerHeader() - Method in class io.grpc.binarylog.v1.GrpcLogEntry
-
.grpc.binarylog.v1.ServerHeader server_header = 7;
- getServerHeader() - Method in interface io.grpc.binarylog.v1.GrpcLogEntryOrBuilder
-
.grpc.binarylog.v1.ServerHeader server_header = 7;
- getServerHeaderBuilder() - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
.grpc.binarylog.v1.ServerHeader server_header = 7;
- getServerHeaderFieldBuilder() - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
.grpc.binarylog.v1.ServerHeader server_header = 7;
- getServerHeaderOrBuilder() - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
.grpc.binarylog.v1.ServerHeader server_header = 7;
- getServerHeaderOrBuilder() - Method in class io.grpc.binarylog.v1.GrpcLogEntry
-
.grpc.binarylog.v1.ServerHeader server_header = 7;
- getServerHeaderOrBuilder() - Method in interface io.grpc.binarylog.v1.GrpcLogEntryOrBuilder
-
.grpc.binarylog.v1.ServerHeader server_header = 7;
- getServerId() - Method in class io.grpc.channelz.v1.GetServerRequest.Builder
-
server_id is the identifier of the specific server to get.
- getServerId() - Method in class io.grpc.channelz.v1.GetServerRequest
-
server_id is the identifier of the specific server to get.
- getServerId() - Method in interface io.grpc.channelz.v1.GetServerRequestOrBuilder
-
server_id is the identifier of the specific server to get.
- getServerId() - Method in class io.grpc.channelz.v1.GetServerSocketsRequest.Builder
-
int64 server_id = 1;
- getServerId() - Method in class io.grpc.channelz.v1.GetServerSocketsRequest
-
int64 server_id = 1;
- getServerId() - Method in interface io.grpc.channelz.v1.GetServerSocketsRequestOrBuilder
-
int64 server_id = 1;
- getServerId() - Method in class io.grpc.channelz.v1.ServerRef.Builder
-
A globally unique identifier for this server.
- getServerId() - Method in class io.grpc.channelz.v1.ServerRef
-
A globally unique identifier for this server.
- getServerId() - Method in interface io.grpc.channelz.v1.ServerRefOrBuilder
-
A globally unique identifier for this server.
- getServerInterceptor(long) - Method in class io.grpc.protobuf.services.BinlogHelper
- getServerInterceptor(String) - Method in class io.grpc.protobuf.services.BinaryLogProvider
-
Returns a
ServerInterceptor
for binary logging. - getServerInterceptor(String) - Method in class io.grpc.protobuf.services.BinaryLogProviderImpl
- getServerList() - Method in class io.grpc.channelz.v1.GetServersResponse.Builder
-
list of servers that the connection detail service knows about.
- getServerList() - Method in class io.grpc.channelz.v1.GetServersResponse
-
list of servers that the connection detail service knows about.
- getServerList() - Method in interface io.grpc.channelz.v1.GetServersResponseOrBuilder
-
list of servers that the connection detail service knows about.
- getServerList() - Method in class io.grpc.lb.v1.LoadBalanceResponse.Builder
-
Contains the list of servers selected by the load balancer.
- getServerList() - Method in class io.grpc.lb.v1.LoadBalanceResponse
-
Contains the list of servers selected by the load balancer.
- getServerList() - Method in interface io.grpc.lb.v1.LoadBalanceResponseOrBuilder
-
Contains the list of servers selected by the load balancer.
- getServerListBuilder() - Method in class io.grpc.lb.v1.LoadBalanceResponse.Builder
-
Contains the list of servers selected by the load balancer.
- getServerListFieldBuilder() - Method in class io.grpc.lb.v1.LoadBalanceResponse.Builder
-
Contains the list of servers selected by the load balancer.
- getServerListOrBuilder() - Method in class io.grpc.lb.v1.LoadBalanceResponse.Builder
-
Contains the list of servers selected by the load balancer.
- getServerListOrBuilder() - Method in class io.grpc.lb.v1.LoadBalanceResponse
-
Contains the list of servers selected by the load balancer.
- getServerListOrBuilder() - Method in interface io.grpc.lb.v1.LoadBalanceResponseOrBuilder
-
Contains the list of servers selected by the load balancer.
- getServerOrBuilder() - Method in class io.grpc.channelz.v1.GetServerResponse.Builder
-
The Server that corresponds to the requested server_id.
- getServerOrBuilder() - Method in class io.grpc.channelz.v1.GetServerResponse
-
The Server that corresponds to the requested server_id.
- getServerOrBuilder() - Method in interface io.grpc.channelz.v1.GetServerResponseOrBuilder
-
The Server that corresponds to the requested server_id.
- getServerOrBuilder(int) - Method in class io.grpc.channelz.v1.GetServersResponse.Builder
-
list of servers that the connection detail service knows about.
- getServerOrBuilder(int) - Method in class io.grpc.channelz.v1.GetServersResponse
-
list of servers that the connection detail service knows about.
- getServerOrBuilder(int) - Method in interface io.grpc.channelz.v1.GetServersResponseOrBuilder
-
list of servers that the connection detail service knows about.
- getServerOrBuilderList() - Method in class io.grpc.channelz.v1.GetServersResponse.Builder
-
list of servers that the connection detail service knows about.
- getServerOrBuilderList() - Method in class io.grpc.channelz.v1.GetServersResponse
-
list of servers that the connection detail service knows about.
- getServerOrBuilderList() - Method in interface io.grpc.channelz.v1.GetServersResponseOrBuilder
-
list of servers that the connection detail service knows about.
- getServerReflectionInfoMethod - Static variable in class io.grpc.reflection.v1.ServerReflectionGrpc
- getServerReflectionInfoMethod - Static variable in class io.grpc.reflection.v1alpha.ServerReflectionGrpc
- getServerReflectionInfoMethod() - Static method in class io.grpc.reflection.v1.ServerReflectionGrpc
- getServerReflectionInfoMethod() - Static method in class io.grpc.reflection.v1alpha.ServerReflectionGrpc
- GetServerRequest - Class in io.grpc.channelz.v1
-
Protobuf type
grpc.channelz.v1.GetServerRequest
- GetServerRequest() - Constructor for class io.grpc.channelz.v1.GetServerRequest
- GetServerRequest(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.channelz.v1.GetServerRequest
- GetServerRequest.Builder - Class in io.grpc.channelz.v1
-
Protobuf type
grpc.channelz.v1.GetServerRequest
- GetServerRequestOrBuilder - Interface in io.grpc.channelz.v1
- GetServerResponse - Class in io.grpc.channelz.v1
-
Protobuf type
grpc.channelz.v1.GetServerResponse
- GetServerResponse() - Constructor for class io.grpc.channelz.v1.GetServerResponse
- GetServerResponse(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.channelz.v1.GetServerResponse
- GetServerResponse.Builder - Class in io.grpc.channelz.v1
-
Protobuf type
grpc.channelz.v1.GetServerResponse
- GetServerResponseOrBuilder - Interface in io.grpc.channelz.v1
- getServers(int) - Method in class io.grpc.lb.v1.ServerList.Builder
-
Contains a list of servers selected by the load balancer.
- getServers(int) - Method in class io.grpc.lb.v1.ServerList
-
Contains a list of servers selected by the load balancer.
- getServers(int) - Method in interface io.grpc.lb.v1.ServerListOrBuilder
-
Contains a list of servers selected by the load balancer.
- getServers(long, int) - Method in class io.grpc.InternalChannelz
-
Returns a server list.
- getServers(GetServersRequest) - Method in class io.grpc.channelz.v1.ChannelzGrpc.ChannelzBlockingStub
-
Gets all servers that exist in the process.
- getServers(GetServersRequest) - Method in class io.grpc.channelz.v1.ChannelzGrpc.ChannelzFutureStub
-
Gets all servers that exist in the process.
- getServers(GetServersRequest, StreamObserver<GetServersResponse>) - Method in interface io.grpc.channelz.v1.ChannelzGrpc.AsyncService
-
Gets all servers that exist in the process.
- getServers(GetServersRequest, StreamObserver<GetServersResponse>) - Method in class io.grpc.channelz.v1.ChannelzGrpc.ChannelzStub
-
Gets all servers that exist in the process.
- getServers(GetServersRequest, StreamObserver<GetServersResponse>) - Method in class io.grpc.protobuf.services.ChannelzService
-
Returns servers.
- getServers(GetServersRequest, StreamObserver<GetServersResponse>) - Method in class io.grpc.services.ChannelzService
-
Deprecated.Returns servers.
- getServersBuilder(int) - Method in class io.grpc.lb.v1.ServerList.Builder
-
Contains a list of servers selected by the load balancer.
- getServersBuilderList() - Method in class io.grpc.lb.v1.ServerList.Builder
-
Contains a list of servers selected by the load balancer.
- getServersCount() - Method in class io.grpc.lb.v1.ServerList.Builder
-
Contains a list of servers selected by the load balancer.
- getServersCount() - Method in class io.grpc.lb.v1.ServerList
-
Contains a list of servers selected by the load balancer.
- getServersCount() - Method in interface io.grpc.lb.v1.ServerListOrBuilder
-
Contains a list of servers selected by the load balancer.
- getServersFieldBuilder() - Method in class io.grpc.lb.v1.ServerList.Builder
- getServersList() - Method in class io.grpc.lb.v1.ServerList.Builder
-
Contains a list of servers selected by the load balancer.
- getServersList() - Method in class io.grpc.lb.v1.ServerList
-
Contains a list of servers selected by the load balancer.
- getServersList() - Method in interface io.grpc.lb.v1.ServerListOrBuilder
-
Contains a list of servers selected by the load balancer.
- getServerSocket(long) - Method in class io.grpc.InternalChannelz
- getServerSockets(long, long, int) - Method in class io.grpc.InternalChannelz
-
Returns socket refs for a server.
- getServerSockets(GetServerSocketsRequest) - Method in class io.grpc.channelz.v1.ChannelzGrpc.ChannelzBlockingStub
-
Gets all server sockets that exist in the process.
- getServerSockets(GetServerSocketsRequest) - Method in class io.grpc.channelz.v1.ChannelzGrpc.ChannelzFutureStub
-
Gets all server sockets that exist in the process.
- getServerSockets(GetServerSocketsRequest, StreamObserver<GetServerSocketsResponse>) - Method in interface io.grpc.channelz.v1.ChannelzGrpc.AsyncService
-
Gets all server sockets that exist in the process.
- getServerSockets(GetServerSocketsRequest, StreamObserver<GetServerSocketsResponse>) - Method in class io.grpc.channelz.v1.ChannelzGrpc.ChannelzStub
-
Gets all server sockets that exist in the process.
- getServerSockets(GetServerSocketsRequest, StreamObserver<GetServerSocketsResponse>) - Method in class io.grpc.protobuf.services.ChannelzService
- getServerSockets(GetServerSocketsRequest, StreamObserver<GetServerSocketsResponse>) - Method in class io.grpc.services.ChannelzService
-
Deprecated.
- GetServerSocketsRequest - Class in io.grpc.channelz.v1
-
Protobuf type
grpc.channelz.v1.GetServerSocketsRequest
- GetServerSocketsRequest() - Constructor for class io.grpc.channelz.v1.GetServerSocketsRequest
- GetServerSocketsRequest(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.channelz.v1.GetServerSocketsRequest
- GetServerSocketsRequest.Builder - Class in io.grpc.channelz.v1
-
Protobuf type
grpc.channelz.v1.GetServerSocketsRequest
- GetServerSocketsRequestOrBuilder - Interface in io.grpc.channelz.v1
- GetServerSocketsResponse - Class in io.grpc.channelz.v1
-
Protobuf type
grpc.channelz.v1.GetServerSocketsResponse
- GetServerSocketsResponse() - Constructor for class io.grpc.channelz.v1.GetServerSocketsResponse
- GetServerSocketsResponse(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.channelz.v1.GetServerSocketsResponse
- GetServerSocketsResponse.Builder - Class in io.grpc.channelz.v1
-
Protobuf type
grpc.channelz.v1.GetServerSocketsResponse
- GetServerSocketsResponseOrBuilder - Interface in io.grpc.channelz.v1
- getServersOrBuilder(int) - Method in class io.grpc.lb.v1.ServerList.Builder
-
Contains a list of servers selected by the load balancer.
- getServersOrBuilder(int) - Method in class io.grpc.lb.v1.ServerList
-
Contains a list of servers selected by the load balancer.
- getServersOrBuilder(int) - Method in interface io.grpc.lb.v1.ServerListOrBuilder
-
Contains a list of servers selected by the load balancer.
- getServersOrBuilderList() - Method in class io.grpc.lb.v1.ServerList.Builder
-
Contains a list of servers selected by the load balancer.
- getServersOrBuilderList() - Method in class io.grpc.lb.v1.ServerList
-
Contains a list of servers selected by the load balancer.
- getServersOrBuilderList() - Method in interface io.grpc.lb.v1.ServerListOrBuilder
-
Contains a list of servers selected by the load balancer.
- GetServersRequest - Class in io.grpc.channelz.v1
-
Protobuf type
grpc.channelz.v1.GetServersRequest
- GetServersRequest() - Constructor for class io.grpc.channelz.v1.GetServersRequest
- GetServersRequest(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.channelz.v1.GetServersRequest
- GetServersRequest.Builder - Class in io.grpc.channelz.v1
-
Protobuf type
grpc.channelz.v1.GetServersRequest
- GetServersRequestOrBuilder - Interface in io.grpc.channelz.v1
- GetServersResponse - Class in io.grpc.channelz.v1
-
Protobuf type
grpc.channelz.v1.GetServersResponse
- GetServersResponse() - Constructor for class io.grpc.channelz.v1.GetServersResponse
- GetServersResponse(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.channelz.v1.GetServersResponse
- GetServersResponse.Builder - Class in io.grpc.channelz.v1
-
Protobuf type
grpc.channelz.v1.GetServersResponse
- GetServersResponseOrBuilder - Interface in io.grpc.channelz.v1
- getService() - Method in class io.grpc.health.v1.HealthCheckRequest.Builder
-
string service = 1;
- getService() - Method in class io.grpc.health.v1.HealthCheckRequest
-
string service = 1;
- getService() - Method in interface io.grpc.health.v1.HealthCheckRequestOrBuilder
-
string service = 1;
- getService() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys.Builder
-
string service = 2;
- getService() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys
-
string service = 2;
- getService() - Method in interface io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeysOrBuilder
-
string service = 2;
- getService() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Name.Builder
-
string service = 1;
- getService() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Name
-
string service = 1;
- getService() - Method in interface io.grpc.lookup.v1.GrpcKeyBuilder.NameOrBuilder
-
string service = 1;
- getService(int) - Method in class io.grpc.reflection.v1.ListServiceResponse.Builder
-
The information of each service may be expanded in the future, so we use ServiceResponse message to encapsulate it.
- getService(int) - Method in class io.grpc.reflection.v1.ListServiceResponse
-
The information of each service may be expanded in the future, so we use ServiceResponse message to encapsulate it.
- getService(int) - Method in interface io.grpc.reflection.v1.ListServiceResponseOrBuilder
-
The information of each service may be expanded in the future, so we use ServiceResponse message to encapsulate it.
- getService(int) - Method in class io.grpc.reflection.v1alpha.ListServiceResponse.Builder
-
The information of each service may be expanded in the future, so we use ServiceResponse message to encapsulate it.
- getService(int) - Method in class io.grpc.reflection.v1alpha.ListServiceResponse
-
The information of each service may be expanded in the future, so we use ServiceResponse message to encapsulate it.
- getService(int) - Method in interface io.grpc.reflection.v1alpha.ListServiceResponseOrBuilder
-
The information of each service may be expanded in the future, so we use ServiceResponse message to encapsulate it.
- getServiceAuthority() - Method in class io.grpc.internal.DnsNameResolver
- getServiceAuthority() - Method in class io.grpc.internal.ForwardingNameResolver
- getServiceAuthority() - Method in class io.grpc.NameResolver
-
Returns the authority used to authenticate connections to servers.
- getServiceAuthority() - Method in class io.grpc.netty.UdsNameResolver
- getServiceBuilder(int) - Method in class io.grpc.reflection.v1.ListServiceResponse.Builder
-
The information of each service may be expanded in the future, so we use ServiceResponse message to encapsulate it.
- getServiceBuilder(int) - Method in class io.grpc.reflection.v1alpha.ListServiceResponse.Builder
-
The information of each service may be expanded in the future, so we use ServiceResponse message to encapsulate it.
- getServiceBuilderList() - Method in class io.grpc.reflection.v1.ListServiceResponse.Builder
-
The information of each service may be expanded in the future, so we use ServiceResponse message to encapsulate it.
- getServiceBuilderList() - Method in class io.grpc.reflection.v1alpha.ListServiceResponse.Builder
-
The information of each service may be expanded in the future, so we use ServiceResponse message to encapsulate it.
- getServiceBytes() - Method in class io.grpc.health.v1.HealthCheckRequest.Builder
-
string service = 1;
- getServiceBytes() - Method in class io.grpc.health.v1.HealthCheckRequest
-
string service = 1;
- getServiceBytes() - Method in interface io.grpc.health.v1.HealthCheckRequestOrBuilder
-
string service = 1;
- getServiceBytes() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys.Builder
-
string service = 2;
- getServiceBytes() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys
-
string service = 2;
- getServiceBytes() - Method in interface io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeysOrBuilder
-
string service = 2;
- getServiceBytes() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Name.Builder
-
string service = 1;
- getServiceBytes() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Name
-
string service = 1;
- getServiceBytes() - Method in interface io.grpc.lookup.v1.GrpcKeyBuilder.NameOrBuilder
-
string service = 1;
- getServiceConfig() - Method in class io.grpc.NameResolver.ResolutionResult
-
Gets the Service Config parsed by
NameResolver.Args.getServiceConfigParser()
. - getServiceConfigParser() - Method in class io.grpc.NameResolver.Args
-
Returns the
NameResolver.ServiceConfigParser
. - getServiceCount() - Method in class io.grpc.reflection.v1.ListServiceResponse.Builder
-
The information of each service may be expanded in the future, so we use ServiceResponse message to encapsulate it.
- getServiceCount() - Method in class io.grpc.reflection.v1.ListServiceResponse
-
The information of each service may be expanded in the future, so we use ServiceResponse message to encapsulate it.
- getServiceCount() - Method in interface io.grpc.reflection.v1.ListServiceResponseOrBuilder
-
The information of each service may be expanded in the future, so we use ServiceResponse message to encapsulate it.
- getServiceCount() - Method in class io.grpc.reflection.v1alpha.ListServiceResponse.Builder
-
The information of each service may be expanded in the future, so we use ServiceResponse message to encapsulate it.
- getServiceCount() - Method in class io.grpc.reflection.v1alpha.ListServiceResponse
-
The information of each service may be expanded in the future, so we use ServiceResponse message to encapsulate it.
- getServiceCount() - Method in interface io.grpc.reflection.v1alpha.ListServiceResponseOrBuilder
-
The information of each service may be expanded in the future, so we use ServiceResponse message to encapsulate it.
- getServiceDescriptor() - Method in class io.grpc.channelz.v1.ChannelzGrpc.ChannelzBaseDescriptorSupplier
- getServiceDescriptor() - Static method in class io.grpc.channelz.v1.ChannelzGrpc
- getServiceDescriptor() - Static method in class io.grpc.health.v1.HealthGrpc
- getServiceDescriptor() - Method in class io.grpc.health.v1.HealthGrpc.HealthBaseDescriptorSupplier
- getServiceDescriptor() - Static method in class io.grpc.lb.v1.LoadBalancerGrpc
- getServiceDescriptor() - Method in class io.grpc.lb.v1.LoadBalancerGrpc.LoadBalancerBaseDescriptorSupplier
- getServiceDescriptor() - Static method in class io.grpc.lookup.v1.RouteLookupServiceGrpc
- getServiceDescriptor() - Method in class io.grpc.lookup.v1.RouteLookupServiceGrpc.RouteLookupServiceBaseDescriptorSupplier
- getServiceDescriptor() - Method in interface io.grpc.protobuf.ProtoServiceDescriptorSupplier
-
Returns service descriptor to the proto service.
- getServiceDescriptor() - Static method in class io.grpc.reflection.v1.ServerReflectionGrpc
- getServiceDescriptor() - Method in class io.grpc.reflection.v1.ServerReflectionGrpc.ServerReflectionBaseDescriptorSupplier
- getServiceDescriptor() - Static method in class io.grpc.reflection.v1alpha.ServerReflectionGrpc
- getServiceDescriptor() - Method in class io.grpc.reflection.v1alpha.ServerReflectionGrpc.ServerReflectionBaseDescriptorSupplier
- getServiceDescriptor() - Method in class io.grpc.ServerServiceDefinition
-
The descriptor for the service.
- getServiceFieldBuilder() - Method in class io.grpc.reflection.v1.ListServiceResponse.Builder
- getServiceFieldBuilder() - Method in class io.grpc.reflection.v1alpha.ListServiceResponse.Builder
- getServiceFileDescriptors() - Method in class io.grpc.protobuf.services.ProtoReflectionServiceV1.FileDescriptorIndex
-
Returns the file descriptors for the indexed services, but not their dependencies.
- getServiceFromName(Map<String, ?>) - Static method in class io.grpc.internal.ServiceConfigUtil
- getServiceList() - Method in class io.grpc.reflection.v1.ListServiceResponse.Builder
-
The information of each service may be expanded in the future, so we use ServiceResponse message to encapsulate it.
- getServiceList() - Method in class io.grpc.reflection.v1.ListServiceResponse
-
The information of each service may be expanded in the future, so we use ServiceResponse message to encapsulate it.
- getServiceList() - Method in interface io.grpc.reflection.v1.ListServiceResponseOrBuilder
-
The information of each service may be expanded in the future, so we use ServiceResponse message to encapsulate it.
- getServiceList() - Method in class io.grpc.reflection.v1alpha.ListServiceResponse.Builder
-
The information of each service may be expanded in the future, so we use ServiceResponse message to encapsulate it.
- getServiceList() - Method in class io.grpc.reflection.v1alpha.ListServiceResponse
-
The information of each service may be expanded in the future, so we use ServiceResponse message to encapsulate it.
- getServiceList() - Method in interface io.grpc.reflection.v1alpha.ListServiceResponseOrBuilder
-
The information of each service may be expanded in the future, so we use ServiceResponse message to encapsulate it.
- getServiceName() - Method in class io.grpc.grpclb.GrpclbConfig
-
If specified, it overrides the name of the service name to be sent to the balancer.
- getServiceName() - Method in class io.grpc.MethodDescriptor
-
A convenience method for
extractFullServiceName(getFullMethodName())
. - getServiceNames() - Method in class io.grpc.protobuf.services.ProtoReflectionServiceV1.FileDescriptorIndex
- getServiceNames() - Method in class io.grpc.protobuf.services.ProtoReflectionServiceV1.ServerReflectionIndex
- getServiceOrBuilder(int) - Method in class io.grpc.reflection.v1.ListServiceResponse.Builder
-
The information of each service may be expanded in the future, so we use ServiceResponse message to encapsulate it.
- getServiceOrBuilder(int) - Method in class io.grpc.reflection.v1.ListServiceResponse
-
The information of each service may be expanded in the future, so we use ServiceResponse message to encapsulate it.
- getServiceOrBuilder(int) - Method in interface io.grpc.reflection.v1.ListServiceResponseOrBuilder
-
The information of each service may be expanded in the future, so we use ServiceResponse message to encapsulate it.
- getServiceOrBuilder(int) - Method in class io.grpc.reflection.v1alpha.ListServiceResponse.Builder
-
The information of each service may be expanded in the future, so we use ServiceResponse message to encapsulate it.
- getServiceOrBuilder(int) - Method in class io.grpc.reflection.v1alpha.ListServiceResponse
-
The information of each service may be expanded in the future, so we use ServiceResponse message to encapsulate it.
- getServiceOrBuilder(int) - Method in interface io.grpc.reflection.v1alpha.ListServiceResponseOrBuilder
-
The information of each service may be expanded in the future, so we use ServiceResponse message to encapsulate it.
- getServiceOrBuilderList() - Method in class io.grpc.reflection.v1.ListServiceResponse.Builder
-
The information of each service may be expanded in the future, so we use ServiceResponse message to encapsulate it.
- getServiceOrBuilderList() - Method in class io.grpc.reflection.v1.ListServiceResponse
-
The information of each service may be expanded in the future, so we use ServiceResponse message to encapsulate it.
- getServiceOrBuilderList() - Method in interface io.grpc.reflection.v1.ListServiceResponseOrBuilder
-
The information of each service may be expanded in the future, so we use ServiceResponse message to encapsulate it.
- getServiceOrBuilderList() - Method in class io.grpc.reflection.v1alpha.ListServiceResponse.Builder
-
The information of each service may be expanded in the future, so we use ServiceResponse message to encapsulate it.
- getServiceOrBuilderList() - Method in class io.grpc.reflection.v1alpha.ListServiceResponse
-
The information of each service may be expanded in the future, so we use ServiceResponse message to encapsulate it.
- getServiceOrBuilderList() - Method in interface io.grpc.reflection.v1alpha.ListServiceResponseOrBuilder
-
The information of each service may be expanded in the future, so we use ServiceResponse message to encapsulate it.
- 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.InternalHandlerRegistry
-
Returns the service definitions in this registry.
- getServices() - Method in class io.grpc.internal.ServerImpl
- getServices() - Method in class io.grpc.internal.ServerImplBuilder.DefaultFallbackRegistry
- 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.
- getSeverity() - Method in class io.grpc.channelz.v1.ChannelTraceEvent.Builder
-
the severity of the trace event
- getSeverity() - Method in class io.grpc.channelz.v1.ChannelTraceEvent
-
the severity of the trace event
- getSeverity() - Method in interface io.grpc.channelz.v1.ChannelTraceEventOrBuilder
-
the severity of the trace event
- getSeverityValue() - Method in class io.grpc.channelz.v1.ChannelTraceEvent.Builder
-
the severity of the trace event
- getSeverityValue() - Method in class io.grpc.channelz.v1.ChannelTraceEvent
-
the severity of the trace event
- getSeverityValue() - Method in interface io.grpc.channelz.v1.ChannelTraceEventOrBuilder
-
the severity of the trace event
- getShort(CharSequence) - Method in class io.grpc.netty.AbstractHttp2Headers
- getShort(CharSequence, short) - Method in class io.grpc.netty.AbstractHttp2Headers
- getShortAndRemove(CharSequence) - Method in class io.grpc.netty.AbstractHttp2Headers
- getShortAndRemove(CharSequence, short) - Method in class io.grpc.netty.AbstractHttp2Headers
- getShutdownStatus() - Method in class io.grpc.netty.ClientTransportLifecycleManager
- getShutdownThrowable() - Method in class io.grpc.netty.ClientTransportLifecycleManager
- getSizeBytes() - Method in class io.grpc.rls.CachingRlsLbClient.BackoffCacheEntry
- getSizeBytes() - Method in class io.grpc.rls.CachingRlsLbClient.CacheEntry
- getSizeBytes() - Method in class io.grpc.rls.CachingRlsLbClient.DataCacheEntry
- getSlot(long) - Method in class io.grpc.rls.AdaptiveThrottler.TimeBasedAccumulator
-
Gets the current slot.
- getSlotEndTime(long) - Method in class io.grpc.rls.AdaptiveThrottler.TimeBasedAccumulator
-
Computes the end boundary since the last bucket can be partial size.
- getSocket() - Method in class io.grpc.channelz.v1.GetSocketResponse.Builder
-
The Socket that corresponds to the requested socket_id.
- getSocket() - Method in class io.grpc.channelz.v1.GetSocketResponse
-
The Socket that corresponds to the requested socket_id.
- getSocket() - Method in interface io.grpc.channelz.v1.GetSocketResponseOrBuilder
-
The Socket that corresponds to the requested socket_id.
- getSocket(long) - Method in class io.grpc.InternalChannelz
-
Returns a socket.
- getSocket(GetSocketRequest) - Method in class io.grpc.channelz.v1.ChannelzGrpc.ChannelzBlockingStub
-
Returns a single Socket or else a NOT_FOUND code.
- getSocket(GetSocketRequest) - Method in class io.grpc.channelz.v1.ChannelzGrpc.ChannelzFutureStub
-
Returns a single Socket or else a NOT_FOUND code.
- getSocket(GetSocketRequest, StreamObserver<GetSocketResponse>) - Method in interface io.grpc.channelz.v1.ChannelzGrpc.AsyncService
-
Returns a single Socket or else a NOT_FOUND code.
- getSocket(GetSocketRequest, StreamObserver<GetSocketResponse>) - Method in class io.grpc.channelz.v1.ChannelzGrpc.ChannelzStub
-
Returns a single Socket or else a NOT_FOUND code.
- getSocket(GetSocketRequest, StreamObserver<GetSocketResponse>) - Method in class io.grpc.protobuf.services.ChannelzService
-
Returns a socket.
- getSocket(GetSocketRequest, StreamObserver<GetSocketResponse>) - Method in class io.grpc.services.ChannelzService
-
Deprecated.Returns a socket.
- getSocketBuilder() - Method in class io.grpc.channelz.v1.GetSocketResponse.Builder
-
The Socket that corresponds to the requested socket_id.
- getSocketFieldBuilder() - Method in class io.grpc.channelz.v1.GetSocketResponse.Builder
-
The Socket that corresponds to the requested socket_id.
- getSocketId() - Method in class io.grpc.channelz.v1.GetSocketRequest.Builder
-
socket_id is the identifier of the specific socket to get.
- getSocketId() - Method in class io.grpc.channelz.v1.GetSocketRequest
-
socket_id is the identifier of the specific socket to get.
- getSocketId() - Method in interface io.grpc.channelz.v1.GetSocketRequestOrBuilder
-
socket_id is the identifier of the specific socket to get.
- getSocketId() - Method in class io.grpc.channelz.v1.SocketRef.Builder
-
The globally unique id for this socket.
- getSocketId() - Method in class io.grpc.channelz.v1.SocketRef
-
The globally unique id for this socket.
- getSocketId() - Method in interface io.grpc.channelz.v1.SocketRefOrBuilder
-
The globally unique id for this socket.
- getSocketOptions(Channel) - Static method in class io.grpc.netty.Utils
- getSocketOrBuilder() - Method in class io.grpc.channelz.v1.GetSocketResponse.Builder
-
The Socket that corresponds to the requested socket_id.
- getSocketOrBuilder() - Method in class io.grpc.channelz.v1.GetSocketResponse
-
The Socket that corresponds to the requested socket_id.
- getSocketOrBuilder() - Method in interface io.grpc.channelz.v1.GetSocketResponseOrBuilder
-
The Socket that corresponds to the requested socket_id.
- getSocketRef(int) - Method in class io.grpc.channelz.v1.Channel.Builder
-
There are no ordering guarantees on the order of sockets.
- getSocketRef(int) - Method in class io.grpc.channelz.v1.Channel
-
There are no ordering guarantees on the order of sockets.
- getSocketRef(int) - Method in interface io.grpc.channelz.v1.ChannelOrBuilder
-
There are no ordering guarantees on the order of sockets.
- getSocketRef(int) - Method in class io.grpc.channelz.v1.GetServerSocketsResponse.Builder
-
list of socket refs that the connection detail service knows about.
- getSocketRef(int) - Method in class io.grpc.channelz.v1.GetServerSocketsResponse
-
list of socket refs that the connection detail service knows about.
- getSocketRef(int) - Method in interface io.grpc.channelz.v1.GetServerSocketsResponseOrBuilder
-
list of socket refs that the connection detail service knows about.
- getSocketRef(int) - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
There are no ordering guarantees on the order of sockets.
- getSocketRef(int) - Method in class io.grpc.channelz.v1.Subchannel
-
There are no ordering guarantees on the order of sockets.
- getSocketRef(int) - Method in interface io.grpc.channelz.v1.SubchannelOrBuilder
-
There are no ordering guarantees on the order of sockets.
- getSocketRefBuilder(int) - Method in class io.grpc.channelz.v1.Channel.Builder
-
There are no ordering guarantees on the order of sockets.
- getSocketRefBuilder(int) - Method in class io.grpc.channelz.v1.GetServerSocketsResponse.Builder
-
list of socket refs that the connection detail service knows about.
- getSocketRefBuilder(int) - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
There are no ordering guarantees on the order of sockets.
- getSocketRefBuilderList() - Method in class io.grpc.channelz.v1.Channel.Builder
-
There are no ordering guarantees on the order of sockets.
- getSocketRefBuilderList() - Method in class io.grpc.channelz.v1.GetServerSocketsResponse.Builder
-
list of socket refs that the connection detail service knows about.
- getSocketRefBuilderList() - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
There are no ordering guarantees on the order of sockets.
- getSocketRefCount() - Method in class io.grpc.channelz.v1.Channel.Builder
-
There are no ordering guarantees on the order of sockets.
- getSocketRefCount() - Method in class io.grpc.channelz.v1.Channel
-
There are no ordering guarantees on the order of sockets.
- getSocketRefCount() - Method in interface io.grpc.channelz.v1.ChannelOrBuilder
-
There are no ordering guarantees on the order of sockets.
- getSocketRefCount() - Method in class io.grpc.channelz.v1.GetServerSocketsResponse.Builder
-
list of socket refs that the connection detail service knows about.
- getSocketRefCount() - Method in class io.grpc.channelz.v1.GetServerSocketsResponse
-
list of socket refs that the connection detail service knows about.
- getSocketRefCount() - Method in interface io.grpc.channelz.v1.GetServerSocketsResponseOrBuilder
-
list of socket refs that the connection detail service knows about.
- getSocketRefCount() - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
There are no ordering guarantees on the order of sockets.
- getSocketRefCount() - Method in class io.grpc.channelz.v1.Subchannel
-
There are no ordering guarantees on the order of sockets.
- getSocketRefCount() - Method in interface io.grpc.channelz.v1.SubchannelOrBuilder
-
There are no ordering guarantees on the order of sockets.
- getSocketRefFieldBuilder() - Method in class io.grpc.channelz.v1.Channel.Builder
- getSocketRefFieldBuilder() - Method in class io.grpc.channelz.v1.GetServerSocketsResponse.Builder
- getSocketRefFieldBuilder() - Method in class io.grpc.channelz.v1.Subchannel.Builder
- getSocketRefList() - Method in class io.grpc.channelz.v1.Channel.Builder
-
There are no ordering guarantees on the order of sockets.
- getSocketRefList() - Method in class io.grpc.channelz.v1.Channel
-
There are no ordering guarantees on the order of sockets.
- getSocketRefList() - Method in interface io.grpc.channelz.v1.ChannelOrBuilder
-
There are no ordering guarantees on the order of sockets.
- getSocketRefList() - Method in class io.grpc.channelz.v1.GetServerSocketsResponse.Builder
-
list of socket refs that the connection detail service knows about.
- getSocketRefList() - Method in class io.grpc.channelz.v1.GetServerSocketsResponse
-
list of socket refs that the connection detail service knows about.
- getSocketRefList() - Method in interface io.grpc.channelz.v1.GetServerSocketsResponseOrBuilder
-
list of socket refs that the connection detail service knows about.
- getSocketRefList() - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
There are no ordering guarantees on the order of sockets.
- getSocketRefList() - Method in class io.grpc.channelz.v1.Subchannel
-
There are no ordering guarantees on the order of sockets.
- getSocketRefList() - Method in interface io.grpc.channelz.v1.SubchannelOrBuilder
-
There are no ordering guarantees on the order of sockets.
- getSocketRefOrBuilder(int) - Method in class io.grpc.channelz.v1.Channel.Builder
-
There are no ordering guarantees on the order of sockets.
- getSocketRefOrBuilder(int) - Method in class io.grpc.channelz.v1.Channel
-
There are no ordering guarantees on the order of sockets.
- getSocketRefOrBuilder(int) - Method in interface io.grpc.channelz.v1.ChannelOrBuilder
-
There are no ordering guarantees on the order of sockets.
- getSocketRefOrBuilder(int) - Method in class io.grpc.channelz.v1.GetServerSocketsResponse.Builder
-
list of socket refs that the connection detail service knows about.
- getSocketRefOrBuilder(int) - Method in class io.grpc.channelz.v1.GetServerSocketsResponse
-
list of socket refs that the connection detail service knows about.
- getSocketRefOrBuilder(int) - Method in interface io.grpc.channelz.v1.GetServerSocketsResponseOrBuilder
-
list of socket refs that the connection detail service knows about.
- getSocketRefOrBuilder(int) - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
There are no ordering guarantees on the order of sockets.
- getSocketRefOrBuilder(int) - Method in class io.grpc.channelz.v1.Subchannel
-
There are no ordering guarantees on the order of sockets.
- getSocketRefOrBuilder(int) - Method in interface io.grpc.channelz.v1.SubchannelOrBuilder
-
There are no ordering guarantees on the order of sockets.
- getSocketRefOrBuilderList() - Method in class io.grpc.channelz.v1.Channel.Builder
-
There are no ordering guarantees on the order of sockets.
- getSocketRefOrBuilderList() - Method in class io.grpc.channelz.v1.Channel
-
There are no ordering guarantees on the order of sockets.
- getSocketRefOrBuilderList() - Method in interface io.grpc.channelz.v1.ChannelOrBuilder
-
There are no ordering guarantees on the order of sockets.
- getSocketRefOrBuilderList() - Method in class io.grpc.channelz.v1.GetServerSocketsResponse.Builder
-
list of socket refs that the connection detail service knows about.
- getSocketRefOrBuilderList() - Method in class io.grpc.channelz.v1.GetServerSocketsResponse
-
list of socket refs that the connection detail service knows about.
- getSocketRefOrBuilderList() - Method in interface io.grpc.channelz.v1.GetServerSocketsResponseOrBuilder
-
list of socket refs that the connection detail service knows about.
- getSocketRefOrBuilderList() - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
There are no ordering guarantees on the order of sockets.
- getSocketRefOrBuilderList() - Method in class io.grpc.channelz.v1.Subchannel
-
There are no ordering guarantees on the order of sockets.
- getSocketRefOrBuilderList() - Method in interface io.grpc.channelz.v1.SubchannelOrBuilder
-
There are no ordering guarantees on the order of sockets.
- GetSocketRequest - Class in io.grpc.channelz.v1
-
Protobuf type
grpc.channelz.v1.GetSocketRequest
- GetSocketRequest() - Constructor for class io.grpc.channelz.v1.GetSocketRequest
- GetSocketRequest(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.channelz.v1.GetSocketRequest
- GetSocketRequest.Builder - Class in io.grpc.channelz.v1
-
Protobuf type
grpc.channelz.v1.GetSocketRequest
- GetSocketRequestOrBuilder - Interface in io.grpc.channelz.v1
- GetSocketResponse - Class in io.grpc.channelz.v1
-
Protobuf type
grpc.channelz.v1.GetSocketResponse
- GetSocketResponse() - Constructor for class io.grpc.channelz.v1.GetSocketResponse
- GetSocketResponse(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.channelz.v1.GetSocketResponse
- GetSocketResponse.Builder - Class in io.grpc.channelz.v1
-
Protobuf type
grpc.channelz.v1.GetSocketResponse
- GetSocketResponseOrBuilder - Interface in io.grpc.channelz.v1
- getStaleAge() - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
After a response has been in the client cache for this amount of time and is re-requested, start an asynchronous RPC to re-validate it.
- getStaleAge() - Method in class io.grpc.lookup.v1.RouteLookupConfig
-
After a response has been in the client cache for this amount of time and is re-requested, start an asynchronous RPC to re-validate it.
- getStaleAge() - Method in interface io.grpc.lookup.v1.RouteLookupConfigOrBuilder
-
After a response has been in the client cache for this amount of time and is re-requested, start an asynchronous RPC to re-validate it.
- getStaleAgeBuilder() - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
After a response has been in the client cache for this amount of time and is re-requested, start an asynchronous RPC to re-validate it.
- getStaleAgeFieldBuilder() - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
After a response has been in the client cache for this amount of time and is re-requested, start an asynchronous RPC to re-validate it.
- getStaleAgeOrBuilder() - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
After a response has been in the client cache for this amount of time and is re-requested, start an asynchronous RPC to re-validate it.
- getStaleAgeOrBuilder() - Method in class io.grpc.lookup.v1.RouteLookupConfig
-
After a response has been in the client cache for this amount of time and is re-requested, start an asynchronous RPC to re-validate it.
- getStaleAgeOrBuilder() - Method in interface io.grpc.lookup.v1.RouteLookupConfigOrBuilder
-
After a response has been in the client cache for this amount of time and is re-requested, start an asynchronous RPC to re-validate it.
- getStaleHeaderData() - Method in class io.grpc.lookup.v1.RouteLookupRequest.Builder
-
For REASON_STALE, the header_data from the stale response, if any.
- getStaleHeaderData() - Method in class io.grpc.lookup.v1.RouteLookupRequest
-
For REASON_STALE, the header_data from the stale response, if any.
- getStaleHeaderData() - Method in interface io.grpc.lookup.v1.RouteLookupRequestOrBuilder
-
For REASON_STALE, the header_data from the stale response, if any.
- getStaleHeaderDataBytes() - Method in class io.grpc.lookup.v1.RouteLookupRequest.Builder
-
For REASON_STALE, the header_data from the stale response, if any.
- getStaleHeaderDataBytes() - Method in class io.grpc.lookup.v1.RouteLookupRequest
-
For REASON_STALE, the header_data from the stale response, if any.
- getStaleHeaderDataBytes() - Method in interface io.grpc.lookup.v1.RouteLookupRequestOrBuilder
-
For REASON_STALE, the header_data from the stale response, if any.
- getStandardName() - Method in class io.grpc.channelz.v1.Security.Tls.Builder
-
The cipher suite name in the RFC 4346 format: https://tools.ietf.org/html/rfc4346#appendix-C
- getStandardName() - Method in class io.grpc.channelz.v1.Security.Tls
-
The cipher suite name in the RFC 4346 format: https://tools.ietf.org/html/rfc4346#appendix-C
- getStandardName() - Method in interface io.grpc.channelz.v1.Security.TlsOrBuilder
-
The cipher suite name in the RFC 4346 format: https://tools.ietf.org/html/rfc4346#appendix-C
- getStandardNameBytes() - Method in class io.grpc.channelz.v1.Security.Tls.Builder
-
The cipher suite name in the RFC 4346 format: https://tools.ietf.org/html/rfc4346#appendix-C
- getStandardNameBytes() - Method in class io.grpc.channelz.v1.Security.Tls
-
The cipher suite name in the RFC 4346 format: https://tools.ietf.org/html/rfc4346#appendix-C
- getStandardNameBytes() - Method in interface io.grpc.channelz.v1.Security.TlsOrBuilder
-
The cipher suite name in the RFC 4346 format: https://tools.ietf.org/html/rfc4346#appendix-C
- getStandardServices() - Static method in class io.grpc.services.AdminInterface
-
Returns a list of gRPC's built-in admin services.
- getStartChannelId() - Method in class io.grpc.channelz.v1.GetTopChannelsRequest.Builder
-
start_channel_id indicates that only channels at or above this id should be included in the results.
- getStartChannelId() - Method in class io.grpc.channelz.v1.GetTopChannelsRequest
-
start_channel_id indicates that only channels at or above this id should be included in the results.
- getStartChannelId() - Method in interface io.grpc.channelz.v1.GetTopChannelsRequestOrBuilder
-
start_channel_id indicates that only channels at or above this id should be included in the results.
- getStartServerId() - Method in class io.grpc.channelz.v1.GetServersRequest.Builder
-
start_server_id indicates that only servers at or above this id should be included in the results.
- getStartServerId() - Method in class io.grpc.channelz.v1.GetServersRequest
-
start_server_id indicates that only servers at or above this id should be included in the results.
- getStartServerId() - Method in interface io.grpc.channelz.v1.GetServersRequestOrBuilder
-
start_server_id indicates that only servers at or above this id should be included in the results.
- getStartSocketId() - Method in class io.grpc.channelz.v1.GetServerSocketsRequest.Builder
-
start_socket_id indicates that only sockets at or above this id should be included in the results.
- getStartSocketId() - Method in class io.grpc.channelz.v1.GetServerSocketsRequest
-
start_socket_id indicates that only sockets at or above this id should be included in the results.
- getStartSocketId() - Method in interface io.grpc.channelz.v1.GetServerSocketsRequestOrBuilder
-
start_socket_id indicates that only sockets at or above this id should be included in the results.
- getState() - Method in class io.grpc.channelz.v1.ChannelConnectivityState.Builder
-
.grpc.channelz.v1.ChannelConnectivityState.State state = 1;
- getState() - Method in class io.grpc.channelz.v1.ChannelConnectivityState
-
.grpc.channelz.v1.ChannelConnectivityState.State state = 1;
- getState() - Method in interface io.grpc.channelz.v1.ChannelConnectivityStateOrBuilder
-
.grpc.channelz.v1.ChannelConnectivityState.State state = 1;
- getState() - Method in class io.grpc.channelz.v1.ChannelData.Builder
-
The connectivity state of the channel or subchannel.
- getState() - Method in class io.grpc.channelz.v1.ChannelData
-
The connectivity state of the channel or subchannel.
- getState() - Method in interface io.grpc.channelz.v1.ChannelDataOrBuilder
-
The connectivity state of the channel or subchannel.
- getState() - Method in class io.grpc.ConnectivityStateInfo
-
Returns the state.
- getState() - Method in class io.grpc.internal.AtomicBackoff
-
Returns the current state.
- getState() - Method in class io.grpc.internal.ConnectivityStateManager
-
Gets the current connectivity state of the channel.
- getState() - Method in class io.grpc.internal.InternalSubchannel
- getState() - Method in class io.grpc.internal.PickFirstLeafLoadBalancer.SubchannelData
- getState() - Method in class io.grpc.rls.LbPolicyConfiguration.ChildPolicyWrapper
- getState(boolean) - Method in class io.grpc.internal.ForwardingManagedChannel
- getState(boolean) - Method in class io.grpc.internal.ManagedChannelImpl
- getState(boolean) - Method in class io.grpc.internal.OobChannel
- getState(boolean) - Method in class io.grpc.ManagedChannel
-
Gets the current connectivity state.
- getState(String) - Method in interface io.grpc.rls.SubchannelStateManager
-
Returns current subchannel state for given subchannel name if exists, otherwise returns
null
. - getState(String) - Method in class io.grpc.rls.SubchannelStateManagerImpl
- getStateBuilder() - Method in class io.grpc.channelz.v1.ChannelData.Builder
-
The connectivity state of the channel or subchannel.
- getStateFieldBuilder() - Method in class io.grpc.channelz.v1.ChannelData.Builder
-
The connectivity state of the channel or subchannel.
- getStateOrBuilder() - Method in class io.grpc.channelz.v1.ChannelData.Builder
-
The connectivity state of the channel or subchannel.
- getStateOrBuilder() - Method in class io.grpc.channelz.v1.ChannelData
-
The connectivity state of the channel or subchannel.
- getStateOrBuilder() - Method in interface io.grpc.channelz.v1.ChannelDataOrBuilder
-
The connectivity state of the channel or subchannel.
- getStateValue() - Method in class io.grpc.channelz.v1.ChannelConnectivityState.Builder
-
.grpc.channelz.v1.ChannelConnectivityState.State state = 1;
- getStateValue() - Method in class io.grpc.channelz.v1.ChannelConnectivityState
-
.grpc.channelz.v1.ChannelConnectivityState.State state = 1;
- getStateValue() - Method in interface io.grpc.channelz.v1.ChannelConnectivityStateOrBuilder
-
.grpc.channelz.v1.ChannelConnectivityState.State state = 1;
- getStats() - Method in class io.grpc.inprocess.InProcessTransport
- getStats() - Method in class io.grpc.internal.DelayedClientTransport
- getStats() - Method in class io.grpc.internal.FailingClientTransport
- getStats() - Method in class io.grpc.internal.ForwardingConnectionClientTransport
- getStats() - Method in class io.grpc.internal.InternalSubchannel
- getStats() - Method in class io.grpc.internal.ManagedChannelImpl
- getStats() - Method in class io.grpc.internal.OobChannel
- 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.
- getStats() - Method in class io.grpc.netty.NettyClientTransport
- getStats() - Method in class io.grpc.netty.NettyServer.ListenSocket
- getStats() - Method in class io.grpc.netty.NettyServerTransport
- getStats() - Method in class io.grpc.servlet.jakarta.ServletServerBuilder.ServerTransportImpl
- getStats() - Method in class io.grpc.servlet.ServletServerBuilder.ServerTransportImpl
- getStatsHelper(Channel) - Method in class io.grpc.netty.NettyClientTransport
- getStatsHelper(Channel) - Method in class io.grpc.netty.NettyServerTransport
- 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.health.v1.HealthCheckResponse.Builder
-
.grpc.health.v1.HealthCheckResponse.ServingStatus status = 1;
- getStatus() - Method in class io.grpc.health.v1.HealthCheckResponse
-
.grpc.health.v1.HealthCheckResponse.ServingStatus status = 1;
- getStatus() - Method in interface io.grpc.health.v1.HealthCheckResponseOrBuilder
-
.grpc.health.v1.HealthCheckResponse.ServingStatus status = 1;
- getStatus() - Method in class io.grpc.InternalConfigSelector.Result
-
Returns the status of the config selection operation.
- getStatus() - Method in class io.grpc.LoadBalancer.PickResult
-
The status associated with this result.
- getStatus() - Method in class io.grpc.netty.ForcefulCloseCommand
- getStatus() - Method in class io.grpc.netty.GracefulCloseCommand
- getStatus() - Method in class io.grpc.rls.CachingRlsLbClient.BackoffCacheEntry
- getStatus() - Method in class io.grpc.rls.CachingRlsLbClient.CachedRouteLookupResponse
- getStatus() - Method in exception class io.grpc.StatusException
-
Returns the status code as a
Status
object. - getStatus() - Method in class io.grpc.StatusOr
-
Returns the status.
- getStatus() - Method in exception class io.grpc.StatusRuntimeException
-
Returns the status code as a
Status
object. - getStatusCode() - Method in class io.grpc.binarylog.v1.Trailer.Builder
-
The gRPC status code.
- getStatusCode() - Method in class io.grpc.binarylog.v1.Trailer
-
The gRPC status code.
- getStatusCode() - Method in interface io.grpc.binarylog.v1.TrailerOrBuilder
-
The gRPC status code.
- getStatusCodesFromList(List<?>) - Static method in class io.grpc.internal.ServiceConfigUtil
- getStatusDetails() - Method in class io.grpc.binarylog.v1.Trailer.Builder
-
The value of the 'grpc-status-details-bin' metadata key.
- getStatusDetails() - Method in class io.grpc.binarylog.v1.Trailer
-
The value of the 'grpc-status-details-bin' metadata key.
- getStatusDetails() - Method in interface io.grpc.binarylog.v1.TrailerOrBuilder
-
The value of the 'grpc-status-details-bin' metadata key.
- getStatusMessage() - Method in class io.grpc.binarylog.v1.Trailer.Builder
-
An original status message before any transport specific encoding.
- getStatusMessage() - Method in class io.grpc.binarylog.v1.Trailer
-
An original status message before any transport specific encoding.
- getStatusMessage() - Method in interface io.grpc.binarylog.v1.TrailerOrBuilder
-
An original status message before any transport specific encoding.
- getStatusMessageBytes() - Method in class io.grpc.binarylog.v1.Trailer.Builder
-
An original status message before any transport specific encoding.
- getStatusMessageBytes() - Method in class io.grpc.binarylog.v1.Trailer
-
An original status message before any transport specific encoding.
- getStatusMessageBytes() - Method in interface io.grpc.binarylog.v1.TrailerOrBuilder
-
An original status message before any transport specific encoding.
- getStatusValue() - Method in class io.grpc.health.v1.HealthCheckResponse.Builder
-
.grpc.health.v1.HealthCheckResponse.ServingStatus status = 1;
- getStatusValue() - Method in class io.grpc.health.v1.HealthCheckResponse
-
.grpc.health.v1.HealthCheckResponse.ServingStatus status = 1;
- getStatusValue() - Method in interface io.grpc.health.v1.HealthCheckResponseOrBuilder
-
.grpc.health.v1.HealthCheckResponse.ServingStatus status = 1;
- getStreamsFailed() - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The number of streams that have ended unsuccessfully: On client side, ended without receiving frame with eos bit set; On server side, ended without sending frame with eos bit set.
- getStreamsFailed() - Method in class io.grpc.channelz.v1.SocketData
-
The number of streams that have ended unsuccessfully: On client side, ended without receiving frame with eos bit set; On server side, ended without sending frame with eos bit set.
- getStreamsFailed() - Method in interface io.grpc.channelz.v1.SocketDataOrBuilder
-
The number of streams that have ended unsuccessfully: On client side, ended without receiving frame with eos bit set; On server side, ended without sending frame with eos bit set.
- getStreamsStarted() - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The number of streams that have been started.
- getStreamsStarted() - Method in class io.grpc.channelz.v1.SocketData
-
The number of streams that have been started.
- getStreamsStarted() - Method in interface io.grpc.channelz.v1.SocketDataOrBuilder
-
The number of streams that have been started.
- getStreamsSucceeded() - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The number of streams that have ended successfully: On client side, received frame with eos bit set; On server side, sent frame with eos bit set.
- getStreamsSucceeded() - Method in class io.grpc.channelz.v1.SocketData
-
The number of streams that have ended successfully: On client side, received frame with eos bit set; On server side, sent frame with eos bit set.
- getStreamsSucceeded() - Method in interface io.grpc.channelz.v1.SocketDataOrBuilder
-
The number of streams that have ended successfully: On client side, received frame with eos bit set; On server side, sent frame with eos bit set.
- getStreamTracerFactories() - Method in class io.grpc.CallOptions
-
Returns an immutable list of
ClientStreamTracerFactory
s. - getStreamTracerFactories() - Method in class io.grpc.inprocess.InProcessServer
- getStreamTracerFactory() - Method in class io.grpc.LoadBalancer.PickResult
-
The stream tracer factory this result was created with.
- getString(Map<String, ?>, String) - Static method in class io.grpc.internal.JsonUtil
-
Gets a string from an object for the given key.
- getStringAsDuration(Map<String, ?>, String) - Static method in class io.grpc.internal.JsonUtil
-
Gets a string from an object for the given key, parsed as a duration (defined by protobuf).
- getStubType(CallOptions) - Static method in class io.grpc.stub.InternalClientCalls
-
Returns
InternalClientCalls.StubType
from call options. - getStubTypeOption() - Static method in class io.grpc.stub.InternalClientCalls
-
Internal accessor for
ClientCalls.STUB_TYPE_OPTION
. - getSubchannel() - Method in class io.grpc.channelz.v1.GetSubchannelResponse.Builder
-
The Subchannel that corresponds to the requested subchannel_id.
- getSubchannel() - Method in class io.grpc.channelz.v1.GetSubchannelResponse
-
The Subchannel that corresponds to the requested subchannel_id.
- getSubchannel() - Method in interface io.grpc.channelz.v1.GetSubchannelResponseOrBuilder
-
The Subchannel that corresponds to the requested subchannel_id.
- getSubchannel() - Method in class io.grpc.internal.OobChannel
- getSubchannel() - Method in class io.grpc.internal.PickFirstLeafLoadBalancer.SubchannelData
- getSubchannel() - Method in class io.grpc.LoadBalancer.PickResult
-
The Subchannel if this result was created by
withSubchannel()
, or null otherwise. - getSubchannel(long) - Method in class io.grpc.InternalChannelz
-
Returns a subchannel.
- getSubchannel(GetSubchannelRequest) - Method in class io.grpc.channelz.v1.ChannelzGrpc.ChannelzBlockingStub
-
Returns a single Subchannel, or else a NOT_FOUND code.
- getSubchannel(GetSubchannelRequest) - Method in class io.grpc.channelz.v1.ChannelzGrpc.ChannelzFutureStub
-
Returns a single Subchannel, or else a NOT_FOUND code.
- getSubchannel(GetSubchannelRequest, StreamObserver<GetSubchannelResponse>) - Method in interface io.grpc.channelz.v1.ChannelzGrpc.AsyncService
-
Returns a single Subchannel, or else a NOT_FOUND code.
- getSubchannel(GetSubchannelRequest, StreamObserver<GetSubchannelResponse>) - Method in class io.grpc.channelz.v1.ChannelzGrpc.ChannelzStub
-
Returns a single Subchannel, or else a NOT_FOUND code.
- getSubchannel(GetSubchannelRequest, StreamObserver<GetSubchannelResponse>) - Method in class io.grpc.protobuf.services.ChannelzService
-
Returns a subchannel.
- getSubchannel(GetSubchannelRequest, StreamObserver<GetSubchannelResponse>) - Method in class io.grpc.services.ChannelzService
-
Deprecated.Returns a subchannel.
- getSubchannelBuilder() - Method in class io.grpc.channelz.v1.GetSubchannelResponse.Builder
-
The Subchannel that corresponds to the requested subchannel_id.
- getSubchannelFieldBuilder() - Method in class io.grpc.channelz.v1.GetSubchannelResponse.Builder
-
The Subchannel that corresponds to the requested subchannel_id.
- getSubchannelId() - Method in class io.grpc.channelz.v1.GetSubchannelRequest.Builder
-
subchannel_id is the identifier of the specific subchannel to get.
- getSubchannelId() - Method in class io.grpc.channelz.v1.GetSubchannelRequest
-
subchannel_id is the identifier of the specific subchannel to get.
- getSubchannelId() - Method in interface io.grpc.channelz.v1.GetSubchannelRequestOrBuilder
-
subchannel_id is the identifier of the specific subchannel to get.
- getSubchannelId() - Method in class io.grpc.channelz.v1.SubchannelRef.Builder
-
The globally unique id for this subchannel.
- getSubchannelId() - Method in class io.grpc.channelz.v1.SubchannelRef
-
The globally unique id for this subchannel.
- getSubchannelId() - Method in interface io.grpc.channelz.v1.SubchannelRefOrBuilder
-
The globally unique id for this subchannel.
- getSubchannelOrBuilder() - Method in class io.grpc.channelz.v1.GetSubchannelResponse.Builder
-
The Subchannel that corresponds to the requested subchannel_id.
- getSubchannelOrBuilder() - Method in class io.grpc.channelz.v1.GetSubchannelResponse
-
The Subchannel that corresponds to the requested subchannel_id.
- getSubchannelOrBuilder() - Method in interface io.grpc.channelz.v1.GetSubchannelResponseOrBuilder
-
The Subchannel that corresponds to the requested subchannel_id.
- getSubchannelPickers() - Method in class io.grpc.util.RoundRobinLoadBalancer.ReadyPicker
- getSubchannelRef() - Method in class io.grpc.channelz.v1.ChannelTraceEvent.Builder
-
.grpc.channelz.v1.SubchannelRef subchannel_ref = 5;
- getSubchannelRef() - Method in class io.grpc.channelz.v1.ChannelTraceEvent
-
.grpc.channelz.v1.SubchannelRef subchannel_ref = 5;
- getSubchannelRef() - Method in interface io.grpc.channelz.v1.ChannelTraceEventOrBuilder
-
.grpc.channelz.v1.SubchannelRef subchannel_ref = 5;
- getSubchannelRef(int) - Method in class io.grpc.channelz.v1.Channel.Builder
-
At most one of 'channel_ref+subchannel_ref' and 'socket' is set.
- getSubchannelRef(int) - Method in class io.grpc.channelz.v1.Channel
-
At most one of 'channel_ref+subchannel_ref' and 'socket' is set.
- getSubchannelRef(int) - Method in interface io.grpc.channelz.v1.ChannelOrBuilder
-
At most one of 'channel_ref+subchannel_ref' and 'socket' is set.
- getSubchannelRef(int) - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
At most one of 'channel_ref+subchannel_ref' and 'socket' is set.
- getSubchannelRef(int) - Method in class io.grpc.channelz.v1.Subchannel
-
At most one of 'channel_ref+subchannel_ref' and 'socket' is set.
- getSubchannelRef(int) - Method in interface io.grpc.channelz.v1.SubchannelOrBuilder
-
At most one of 'channel_ref+subchannel_ref' and 'socket' is set.
- getSubchannelRefBuilder() - Method in class io.grpc.channelz.v1.ChannelTraceEvent.Builder
-
.grpc.channelz.v1.SubchannelRef subchannel_ref = 5;
- getSubchannelRefBuilder(int) - Method in class io.grpc.channelz.v1.Channel.Builder
-
At most one of 'channel_ref+subchannel_ref' and 'socket' is set.
- getSubchannelRefBuilder(int) - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
At most one of 'channel_ref+subchannel_ref' and 'socket' is set.
- getSubchannelRefBuilderList() - Method in class io.grpc.channelz.v1.Channel.Builder
-
At most one of 'channel_ref+subchannel_ref' and 'socket' is set.
- getSubchannelRefBuilderList() - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
At most one of 'channel_ref+subchannel_ref' and 'socket' is set.
- getSubchannelRefCount() - Method in class io.grpc.channelz.v1.Channel.Builder
-
At most one of 'channel_ref+subchannel_ref' and 'socket' is set.
- getSubchannelRefCount() - Method in class io.grpc.channelz.v1.Channel
-
At most one of 'channel_ref+subchannel_ref' and 'socket' is set.
- getSubchannelRefCount() - Method in interface io.grpc.channelz.v1.ChannelOrBuilder
-
At most one of 'channel_ref+subchannel_ref' and 'socket' is set.
- getSubchannelRefCount() - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
At most one of 'channel_ref+subchannel_ref' and 'socket' is set.
- getSubchannelRefCount() - Method in class io.grpc.channelz.v1.Subchannel
-
At most one of 'channel_ref+subchannel_ref' and 'socket' is set.
- getSubchannelRefCount() - Method in interface io.grpc.channelz.v1.SubchannelOrBuilder
-
At most one of 'channel_ref+subchannel_ref' and 'socket' is set.
- getSubchannelRefFieldBuilder() - Method in class io.grpc.channelz.v1.Channel.Builder
- getSubchannelRefFieldBuilder() - Method in class io.grpc.channelz.v1.ChannelTraceEvent.Builder
-
.grpc.channelz.v1.SubchannelRef subchannel_ref = 5;
- getSubchannelRefFieldBuilder() - Method in class io.grpc.channelz.v1.Subchannel.Builder
- getSubchannelRefList() - Method in class io.grpc.channelz.v1.Channel.Builder
-
At most one of 'channel_ref+subchannel_ref' and 'socket' is set.
- getSubchannelRefList() - Method in class io.grpc.channelz.v1.Channel
-
At most one of 'channel_ref+subchannel_ref' and 'socket' is set.
- getSubchannelRefList() - Method in interface io.grpc.channelz.v1.ChannelOrBuilder
-
At most one of 'channel_ref+subchannel_ref' and 'socket' is set.
- getSubchannelRefList() - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
At most one of 'channel_ref+subchannel_ref' and 'socket' is set.
- getSubchannelRefList() - Method in class io.grpc.channelz.v1.Subchannel
-
At most one of 'channel_ref+subchannel_ref' and 'socket' is set.
- getSubchannelRefList() - Method in interface io.grpc.channelz.v1.SubchannelOrBuilder
-
At most one of 'channel_ref+subchannel_ref' and 'socket' is set.
- getSubchannelRefOrBuilder() - Method in class io.grpc.channelz.v1.ChannelTraceEvent.Builder
-
.grpc.channelz.v1.SubchannelRef subchannel_ref = 5;
- getSubchannelRefOrBuilder() - Method in class io.grpc.channelz.v1.ChannelTraceEvent
-
.grpc.channelz.v1.SubchannelRef subchannel_ref = 5;
- getSubchannelRefOrBuilder() - Method in interface io.grpc.channelz.v1.ChannelTraceEventOrBuilder
-
.grpc.channelz.v1.SubchannelRef subchannel_ref = 5;
- getSubchannelRefOrBuilder(int) - Method in class io.grpc.channelz.v1.Channel.Builder
-
At most one of 'channel_ref+subchannel_ref' and 'socket' is set.
- getSubchannelRefOrBuilder(int) - Method in class io.grpc.channelz.v1.Channel
-
At most one of 'channel_ref+subchannel_ref' and 'socket' is set.
- getSubchannelRefOrBuilder(int) - Method in interface io.grpc.channelz.v1.ChannelOrBuilder
-
At most one of 'channel_ref+subchannel_ref' and 'socket' is set.
- getSubchannelRefOrBuilder(int) - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
At most one of 'channel_ref+subchannel_ref' and 'socket' is set.
- getSubchannelRefOrBuilder(int) - Method in class io.grpc.channelz.v1.Subchannel
-
At most one of 'channel_ref+subchannel_ref' and 'socket' is set.
- getSubchannelRefOrBuilder(int) - Method in interface io.grpc.channelz.v1.SubchannelOrBuilder
-
At most one of 'channel_ref+subchannel_ref' and 'socket' is set.
- getSubchannelRefOrBuilderList() - Method in class io.grpc.channelz.v1.Channel.Builder
-
At most one of 'channel_ref+subchannel_ref' and 'socket' is set.
- getSubchannelRefOrBuilderList() - Method in class io.grpc.channelz.v1.Channel
-
At most one of 'channel_ref+subchannel_ref' and 'socket' is set.
- getSubchannelRefOrBuilderList() - Method in interface io.grpc.channelz.v1.ChannelOrBuilder
-
At most one of 'channel_ref+subchannel_ref' and 'socket' is set.
- getSubchannelRefOrBuilderList() - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
At most one of 'channel_ref+subchannel_ref' and 'socket' is set.
- getSubchannelRefOrBuilderList() - Method in class io.grpc.channelz.v1.Subchannel
-
At most one of 'channel_ref+subchannel_ref' and 'socket' is set.
- getSubchannelRefOrBuilderList() - Method in interface io.grpc.channelz.v1.SubchannelOrBuilder
-
At most one of 'channel_ref+subchannel_ref' and 'socket' is set.
- GetSubchannelRequest - Class in io.grpc.channelz.v1
-
Protobuf type
grpc.channelz.v1.GetSubchannelRequest
- GetSubchannelRequest() - Constructor for class io.grpc.channelz.v1.GetSubchannelRequest
- GetSubchannelRequest(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.channelz.v1.GetSubchannelRequest
- GetSubchannelRequest.Builder - Class in io.grpc.channelz.v1
-
Protobuf type
grpc.channelz.v1.GetSubchannelRequest
- GetSubchannelRequestOrBuilder - Interface in io.grpc.channelz.v1
- GetSubchannelResponse - Class in io.grpc.channelz.v1
-
Protobuf type
grpc.channelz.v1.GetSubchannelResponse
- GetSubchannelResponse() - Constructor for class io.grpc.channelz.v1.GetSubchannelResponse
- GetSubchannelResponse(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.channelz.v1.GetSubchannelResponse
- GetSubchannelResponse.Builder - Class in io.grpc.channelz.v1
-
Protobuf type
grpc.channelz.v1.GetSubchannelResponse
- GetSubchannelResponseOrBuilder - Interface in io.grpc.channelz.v1
- getSubchannels() - Method in class io.grpc.util.OutlierDetectionLoadBalancer.EndpointTracker
- getSummary() - Method in class io.grpc.channelz.v1.GetSocketRequest.Builder
-
If true, the response will contain only high level information that is inexpensive to obtain.
- getSummary() - Method in class io.grpc.channelz.v1.GetSocketRequest
-
If true, the response will contain only high level information that is inexpensive to obtain.
- getSummary() - Method in interface io.grpc.channelz.v1.GetSocketRequestOrBuilder
-
If true, the response will contain only high level information that is inexpensive to obtain.
- getSupportedSocketAddressTypes() - Method in class io.grpc.inprocess.InProcessChannelBuilder.InProcessClientTransportFactory
- getSupportedSocketAddressTypes() - Method in class io.grpc.internal.CallCredentialsApplyingTransportFactory
- getSupportedSocketAddressTypes() - Method in interface io.grpc.internal.ClientTransportFactory
-
Returns the
SocketAddress
types this transport supports. - getSupportedSocketAddressTypes() - Method in class io.grpc.ManagedChannelProvider
-
Returns the
SocketAddress
types this ManagedChannelProvider supports. - getSupportedSocketAddressTypes() - Static method in class io.grpc.netty.NettyChannelBuilder
- getSupportedSocketAddressTypes() - Method in class io.grpc.netty.NettyChannelBuilder.NettyTransportFactory
- getSupportedSocketAddressTypes() - Method in class io.grpc.netty.NettyChannelProvider
- getSupportedSocketAddressTypes() - Method in class io.grpc.netty.UdsNettyChannelProvider
- getSynchronizationContext() - Method in class io.grpc.internal.ManagedChannelImpl.LbHelperImpl
- getSynchronizationContext() - Method in class io.grpc.LoadBalancer.Helper
-
Returns a
SynchronizationContext
that runs tasks in the same Synchronization Context as that the callback methods on theLoadBalancer
interface are run in. - getSynchronizationContext() - Method in class io.grpc.NameResolver.Args
-
Returns the
SynchronizationContext
whereNameResolver.start(Listener2)
,NameResolver.shutdown()
andNameResolver.refresh()
are run from. - getSynchronizationContext() - Method in class io.grpc.util.ForwardingLoadBalancerHelper
- getSystemTicker() - Static method in class io.grpc.Deadline
-
Returns the ticker that's based on system clock.
- getTarget() - Method in class io.grpc.channelz.v1.ChannelData.Builder
-
The target this channel originally tried to connect to.
- getTarget() - Method in class io.grpc.channelz.v1.ChannelData
-
The target this channel originally tried to connect to.
- getTarget() - Method in interface io.grpc.channelz.v1.ChannelDataOrBuilder
-
The target this channel originally tried to connect to.
- getTarget() - Method in class io.grpc.rls.LbPolicyConfiguration.ChildPolicyWrapper
- getTargetAddress() - Method in class io.grpc.HttpConnectProxiedSocketAddress
-
Returns the address to the target server.
- getTargetBytes() - Method in class io.grpc.channelz.v1.ChannelData.Builder
-
The target this channel originally tried to connect to.
- getTargetBytes() - Method in class io.grpc.channelz.v1.ChannelData
-
The target this channel originally tried to connect to.
- getTargetBytes() - Method in interface io.grpc.channelz.v1.ChannelDataOrBuilder
-
The target this channel originally tried to connect to.
- getTargetPathFromUri(URI) - Static method in class io.grpc.netty.UdsNameResolverProvider
- getTargets(int) - Method in class io.grpc.lookup.v1.RouteLookupResponse.Builder
-
Prioritized list (best one first) of addressable entities to use for routing, using syntax requested by the request target_type.
- getTargets(int) - Method in class io.grpc.lookup.v1.RouteLookupResponse
-
Prioritized list (best one first) of addressable entities to use for routing, using syntax requested by the request target_type.
- getTargets(int) - Method in interface io.grpc.lookup.v1.RouteLookupResponseOrBuilder
-
Prioritized list (best one first) of addressable entities to use for routing, using syntax requested by the request target_type.
- getTargetsBytes(int) - Method in class io.grpc.lookup.v1.RouteLookupResponse.Builder
-
Prioritized list (best one first) of addressable entities to use for routing, using syntax requested by the request target_type.
- getTargetsBytes(int) - Method in class io.grpc.lookup.v1.RouteLookupResponse
-
Prioritized list (best one first) of addressable entities to use for routing, using syntax requested by the request target_type.
- getTargetsBytes(int) - Method in interface io.grpc.lookup.v1.RouteLookupResponseOrBuilder
-
Prioritized list (best one first) of addressable entities to use for routing, using syntax requested by the request target_type.
- getTargetsCount() - Method in class io.grpc.lookup.v1.RouteLookupResponse.Builder
-
Prioritized list (best one first) of addressable entities to use for routing, using syntax requested by the request target_type.
- getTargetsCount() - Method in class io.grpc.lookup.v1.RouteLookupResponse
-
Prioritized list (best one first) of addressable entities to use for routing, using syntax requested by the request target_type.
- getTargetsCount() - Method in interface io.grpc.lookup.v1.RouteLookupResponseOrBuilder
-
Prioritized list (best one first) of addressable entities to use for routing, using syntax requested by the request target_type.
- getTargetsList() - Method in class io.grpc.lookup.v1.RouteLookupResponse.Builder
-
Prioritized list (best one first) of addressable entities to use for routing, using syntax requested by the request target_type.
- getTargetsList() - Method in class io.grpc.lookup.v1.RouteLookupResponse
-
Prioritized list (best one first) of addressable entities to use for routing, using syntax requested by the request target_type.
- getTargetsList() - Method in interface io.grpc.lookup.v1.RouteLookupResponseOrBuilder
-
Prioritized list (best one first) of addressable entities to use for routing, using syntax requested by the request target_type.
- getTargetType() - Method in class io.grpc.lookup.v1.RouteLookupRequest.Builder
-
Target type allows the client to specify what kind of target format it would like from RLS to allow it to find the regional server, e.g.
- getTargetType() - Method in class io.grpc.lookup.v1.RouteLookupRequest
-
Target type allows the client to specify what kind of target format it would like from RLS to allow it to find the regional server, e.g.
- getTargetType() - Method in interface io.grpc.lookup.v1.RouteLookupRequestOrBuilder
-
Target type allows the client to specify what kind of target format it would like from RLS to allow it to find the regional server, e.g.
- getTargetTypeBytes() - Method in class io.grpc.lookup.v1.RouteLookupRequest.Builder
-
Target type allows the client to specify what kind of target format it would like from RLS to allow it to find the regional server, e.g.
- getTargetTypeBytes() - Method in class io.grpc.lookup.v1.RouteLookupRequest
-
Target type allows the client to specify what kind of target format it would like from RLS to allow it to find the regional server, e.g.
- getTargetTypeBytes() - Method in interface io.grpc.lookup.v1.RouteLookupRequestOrBuilder
-
Target type allows the client to specify what kind of target format it would like from RLS to allow it to find the regional server, e.g.
- getTcpiAdvmss() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_advmss = 28;
- getTcpiAdvmss() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo
-
uint32 tcpi_advmss = 28;
- getTcpiAdvmss() - Method in interface io.grpc.channelz.v1.SocketOptionTcpInfoOrBuilder
-
uint32 tcpi_advmss = 28;
- getTcpiAto() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_ato = 10;
- getTcpiAto() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo
-
uint32 tcpi_ato = 10;
- getTcpiAto() - Method in interface io.grpc.channelz.v1.SocketOptionTcpInfoOrBuilder
-
uint32 tcpi_ato = 10;
- getTcpiBackoff() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_backoff = 5;
- getTcpiBackoff() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo
-
uint32 tcpi_backoff = 5;
- getTcpiBackoff() - Method in interface io.grpc.channelz.v1.SocketOptionTcpInfoOrBuilder
-
uint32 tcpi_backoff = 5;
- getTcpiCaState() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_ca_state = 2;
- getTcpiCaState() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo
-
uint32 tcpi_ca_state = 2;
- getTcpiCaState() - Method in interface io.grpc.channelz.v1.SocketOptionTcpInfoOrBuilder
-
uint32 tcpi_ca_state = 2;
- getTcpiFackets() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_fackets = 17;
- getTcpiFackets() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo
-
uint32 tcpi_fackets = 17;
- getTcpiFackets() - Method in interface io.grpc.channelz.v1.SocketOptionTcpInfoOrBuilder
-
uint32 tcpi_fackets = 17;
- getTcpiLastAckRecv() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_last_ack_recv = 21;
- getTcpiLastAckRecv() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo
-
uint32 tcpi_last_ack_recv = 21;
- getTcpiLastAckRecv() - Method in interface io.grpc.channelz.v1.SocketOptionTcpInfoOrBuilder
-
uint32 tcpi_last_ack_recv = 21;
- getTcpiLastAckSent() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_last_ack_sent = 19;
- getTcpiLastAckSent() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo
-
uint32 tcpi_last_ack_sent = 19;
- getTcpiLastAckSent() - Method in interface io.grpc.channelz.v1.SocketOptionTcpInfoOrBuilder
-
uint32 tcpi_last_ack_sent = 19;
- getTcpiLastDataRecv() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_last_data_recv = 20;
- getTcpiLastDataRecv() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo
-
uint32 tcpi_last_data_recv = 20;
- getTcpiLastDataRecv() - Method in interface io.grpc.channelz.v1.SocketOptionTcpInfoOrBuilder
-
uint32 tcpi_last_data_recv = 20;
- getTcpiLastDataSent() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_last_data_sent = 18;
- getTcpiLastDataSent() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo
-
uint32 tcpi_last_data_sent = 18;
- getTcpiLastDataSent() - Method in interface io.grpc.channelz.v1.SocketOptionTcpInfoOrBuilder
-
uint32 tcpi_last_data_sent = 18;
- getTcpiLost() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_lost = 15;
- getTcpiLost() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo
-
uint32 tcpi_lost = 15;
- getTcpiLost() - Method in interface io.grpc.channelz.v1.SocketOptionTcpInfoOrBuilder
-
uint32 tcpi_lost = 15;
- getTcpiOptions() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_options = 6;
- getTcpiOptions() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo
-
uint32 tcpi_options = 6;
- getTcpiOptions() - Method in interface io.grpc.channelz.v1.SocketOptionTcpInfoOrBuilder
-
uint32 tcpi_options = 6;
- getTcpipAddress() - Method in class io.grpc.channelz.v1.Address.Builder
-
.grpc.channelz.v1.Address.TcpIpAddress tcpip_address = 1;
- getTcpipAddress() - Method in class io.grpc.channelz.v1.Address
-
.grpc.channelz.v1.Address.TcpIpAddress tcpip_address = 1;
- getTcpipAddress() - Method in interface io.grpc.channelz.v1.AddressOrBuilder
-
.grpc.channelz.v1.Address.TcpIpAddress tcpip_address = 1;
- getTcpipAddressBuilder() - Method in class io.grpc.channelz.v1.Address.Builder
-
.grpc.channelz.v1.Address.TcpIpAddress tcpip_address = 1;
- getTcpipAddressFieldBuilder() - Method in class io.grpc.channelz.v1.Address.Builder
-
.grpc.channelz.v1.Address.TcpIpAddress tcpip_address = 1;
- getTcpipAddressOrBuilder() - Method in class io.grpc.channelz.v1.Address.Builder
-
.grpc.channelz.v1.Address.TcpIpAddress tcpip_address = 1;
- getTcpipAddressOrBuilder() - Method in class io.grpc.channelz.v1.Address
-
.grpc.channelz.v1.Address.TcpIpAddress tcpip_address = 1;
- getTcpipAddressOrBuilder() - Method in interface io.grpc.channelz.v1.AddressOrBuilder
-
.grpc.channelz.v1.Address.TcpIpAddress tcpip_address = 1;
- getTcpiPmtu() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_pmtu = 22;
- getTcpiPmtu() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo
-
uint32 tcpi_pmtu = 22;
- getTcpiPmtu() - Method in interface io.grpc.channelz.v1.SocketOptionTcpInfoOrBuilder
-
uint32 tcpi_pmtu = 22;
- getTcpiProbes() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_probes = 4;
- getTcpiProbes() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo
-
uint32 tcpi_probes = 4;
- getTcpiProbes() - Method in interface io.grpc.channelz.v1.SocketOptionTcpInfoOrBuilder
-
uint32 tcpi_probes = 4;
- getTcpiRcvMss() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_rcv_mss = 12;
- getTcpiRcvMss() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo
-
uint32 tcpi_rcv_mss = 12;
- getTcpiRcvMss() - Method in interface io.grpc.channelz.v1.SocketOptionTcpInfoOrBuilder
-
uint32 tcpi_rcv_mss = 12;
- getTcpiRcvSsthresh() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_rcv_ssthresh = 23;
- getTcpiRcvSsthresh() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo
-
uint32 tcpi_rcv_ssthresh = 23;
- getTcpiRcvSsthresh() - Method in interface io.grpc.channelz.v1.SocketOptionTcpInfoOrBuilder
-
uint32 tcpi_rcv_ssthresh = 23;
- getTcpiRcvWscale() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_rcv_wscale = 8;
- getTcpiRcvWscale() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo
-
uint32 tcpi_rcv_wscale = 8;
- getTcpiRcvWscale() - Method in interface io.grpc.channelz.v1.SocketOptionTcpInfoOrBuilder
-
uint32 tcpi_rcv_wscale = 8;
- getTcpiReordering() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_reordering = 29;
- getTcpiReordering() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo
-
uint32 tcpi_reordering = 29;
- getTcpiReordering() - Method in interface io.grpc.channelz.v1.SocketOptionTcpInfoOrBuilder
-
uint32 tcpi_reordering = 29;
- getTcpiRetrans() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_retrans = 16;
- getTcpiRetrans() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo
-
uint32 tcpi_retrans = 16;
- getTcpiRetrans() - Method in interface io.grpc.channelz.v1.SocketOptionTcpInfoOrBuilder
-
uint32 tcpi_retrans = 16;
- getTcpiRetransmits() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_retransmits = 3;
- getTcpiRetransmits() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo
-
uint32 tcpi_retransmits = 3;
- getTcpiRetransmits() - Method in interface io.grpc.channelz.v1.SocketOptionTcpInfoOrBuilder
-
uint32 tcpi_retransmits = 3;
- getTcpiRto() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_rto = 9;
- getTcpiRto() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo
-
uint32 tcpi_rto = 9;
- getTcpiRto() - Method in interface io.grpc.channelz.v1.SocketOptionTcpInfoOrBuilder
-
uint32 tcpi_rto = 9;
- getTcpiRtt() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_rtt = 24;
- getTcpiRtt() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo
-
uint32 tcpi_rtt = 24;
- getTcpiRtt() - Method in interface io.grpc.channelz.v1.SocketOptionTcpInfoOrBuilder
-
uint32 tcpi_rtt = 24;
- getTcpiRttvar() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_rttvar = 25;
- getTcpiRttvar() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo
-
uint32 tcpi_rttvar = 25;
- getTcpiRttvar() - Method in interface io.grpc.channelz.v1.SocketOptionTcpInfoOrBuilder
-
uint32 tcpi_rttvar = 25;
- getTcpiSacked() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_sacked = 14;
- getTcpiSacked() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo
-
uint32 tcpi_sacked = 14;
- getTcpiSacked() - Method in interface io.grpc.channelz.v1.SocketOptionTcpInfoOrBuilder
-
uint32 tcpi_sacked = 14;
- getTcpiSndCwnd() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_snd_cwnd = 27;
- getTcpiSndCwnd() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo
-
uint32 tcpi_snd_cwnd = 27;
- getTcpiSndCwnd() - Method in interface io.grpc.channelz.v1.SocketOptionTcpInfoOrBuilder
-
uint32 tcpi_snd_cwnd = 27;
- getTcpiSndMss() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_snd_mss = 11;
- getTcpiSndMss() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo
-
uint32 tcpi_snd_mss = 11;
- getTcpiSndMss() - Method in interface io.grpc.channelz.v1.SocketOptionTcpInfoOrBuilder
-
uint32 tcpi_snd_mss = 11;
- getTcpiSndSsthresh() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_snd_ssthresh = 26;
- getTcpiSndSsthresh() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo
-
uint32 tcpi_snd_ssthresh = 26;
- getTcpiSndSsthresh() - Method in interface io.grpc.channelz.v1.SocketOptionTcpInfoOrBuilder
-
uint32 tcpi_snd_ssthresh = 26;
- getTcpiSndWscale() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_snd_wscale = 7;
- getTcpiSndWscale() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo
-
uint32 tcpi_snd_wscale = 7;
- getTcpiSndWscale() - Method in interface io.grpc.channelz.v1.SocketOptionTcpInfoOrBuilder
-
uint32 tcpi_snd_wscale = 7;
- getTcpiState() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_state = 1;
- getTcpiState() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo
-
uint32 tcpi_state = 1;
- getTcpiState() - Method in interface io.grpc.channelz.v1.SocketOptionTcpInfoOrBuilder
-
uint32 tcpi_state = 1;
- getTcpiUnacked() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_unacked = 13;
- getTcpiUnacked() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo
-
uint32 tcpi_unacked = 13;
- getTcpiUnacked() - Method in interface io.grpc.channelz.v1.SocketOptionTcpInfoOrBuilder
-
uint32 tcpi_unacked = 13;
- getThreadFactory(String, boolean) - Static method in class io.grpc.internal.GrpcUtil
-
Get a
ThreadFactory
suitable for use in the current environment. - getThrottlePolicy(Map<String, ?>) - Static method in class io.grpc.internal.ServiceConfigUtil
- getThrottleProbability(long) - Method in class io.grpc.rls.AdaptiveThrottler
-
Calculates throttleProbability.
- getTimeMillis(CharSequence) - Method in class io.grpc.netty.AbstractHttp2Headers
- getTimeMillis(CharSequence, long) - Method in class io.grpc.netty.AbstractHttp2Headers
- getTimeMillisAndRemove(CharSequence) - Method in class io.grpc.netty.AbstractHttp2Headers
- getTimeMillisAndRemove(CharSequence, long) - Method in class io.grpc.netty.AbstractHttp2Headers
- getTimeout() - Method in class io.grpc.binarylog.v1.ClientHeader.Builder
-
the RPC timeout
- getTimeout() - Method in class io.grpc.binarylog.v1.ClientHeader
-
the RPC timeout
- getTimeout() - Method in interface io.grpc.binarylog.v1.ClientHeaderOrBuilder
-
the RPC timeout
- getTimeoutBuilder() - Method in class io.grpc.binarylog.v1.ClientHeader.Builder
-
the RPC timeout
- getTimeoutFieldBuilder() - Method in class io.grpc.binarylog.v1.ClientHeader.Builder
-
the RPC timeout
- getTimeoutFromMethodConfig(Map<String, ?>) - Static method in class io.grpc.internal.ServiceConfigUtil
-
Returns the number of nanoseconds of timeout for the given method config.
- getTimeoutOrBuilder() - Method in class io.grpc.binarylog.v1.ClientHeader.Builder
-
the RPC timeout
- getTimeoutOrBuilder() - Method in class io.grpc.binarylog.v1.ClientHeader
-
the RPC timeout
- getTimeoutOrBuilder() - Method in interface io.grpc.binarylog.v1.ClientHeaderOrBuilder
-
the RPC timeout
- getTimestamp() - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
The timestamp of the binary log message
- getTimestamp() - Method in class io.grpc.binarylog.v1.GrpcLogEntry
-
The timestamp of the binary log message
- getTimestamp() - Method in interface io.grpc.binarylog.v1.GrpcLogEntryOrBuilder
-
The timestamp of the binary log message
- getTimestamp() - Method in class io.grpc.channelz.v1.ChannelTraceEvent.Builder
-
When this event occurred.
- getTimestamp() - Method in class io.grpc.channelz.v1.ChannelTraceEvent
-
When this event occurred.
- getTimestamp() - Method in interface io.grpc.channelz.v1.ChannelTraceEventOrBuilder
-
When this event occurred.
- getTimestamp() - Method in class io.grpc.lb.v1.ClientStats.Builder
-
The timestamp of generating the report.
- getTimestamp() - Method in class io.grpc.lb.v1.ClientStats
-
The timestamp of generating the report.
- getTimestamp() - Method in interface io.grpc.lb.v1.ClientStatsOrBuilder
-
The timestamp of generating the report.
- getTimestampBuilder() - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
The timestamp of the binary log message
- getTimestampBuilder() - Method in class io.grpc.channelz.v1.ChannelTraceEvent.Builder
-
When this event occurred.
- getTimestampBuilder() - Method in class io.grpc.lb.v1.ClientStats.Builder
-
The timestamp of generating the report.
- getTimestampFieldBuilder() - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
The timestamp of the binary log message
- getTimestampFieldBuilder() - Method in class io.grpc.channelz.v1.ChannelTraceEvent.Builder
-
When this event occurred.
- getTimestampFieldBuilder() - Method in class io.grpc.lb.v1.ClientStats.Builder
-
The timestamp of generating the report.
- getTimestampOrBuilder() - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
The timestamp of the binary log message
- getTimestampOrBuilder() - Method in class io.grpc.binarylog.v1.GrpcLogEntry
-
The timestamp of the binary log message
- getTimestampOrBuilder() - Method in interface io.grpc.binarylog.v1.GrpcLogEntryOrBuilder
-
The timestamp of the binary log message
- getTimestampOrBuilder() - Method in class io.grpc.channelz.v1.ChannelTraceEvent.Builder
-
When this event occurred.
- getTimestampOrBuilder() - Method in class io.grpc.channelz.v1.ChannelTraceEvent
-
When this event occurred.
- getTimestampOrBuilder() - Method in interface io.grpc.channelz.v1.ChannelTraceEventOrBuilder
-
When this event occurred.
- getTimestampOrBuilder() - Method in class io.grpc.lb.v1.ClientStats.Builder
-
The timestamp of generating the report.
- getTimestampOrBuilder() - Method in class io.grpc.lb.v1.ClientStats
-
The timestamp of generating the report.
- getTimestampOrBuilder() - Method in interface io.grpc.lb.v1.ClientStatsOrBuilder
-
The timestamp of generating the report.
- getTls() - Method in class io.grpc.channelz.v1.Security.Builder
-
.grpc.channelz.v1.Security.Tls tls = 1;
- getTls() - Method in class io.grpc.channelz.v1.Security
-
.grpc.channelz.v1.Security.Tls tls = 1;
- getTls() - Method in interface io.grpc.channelz.v1.SecurityOrBuilder
-
.grpc.channelz.v1.Security.Tls tls = 1;
- getTlsBuilder() - Method in class io.grpc.channelz.v1.Security.Builder
-
.grpc.channelz.v1.Security.Tls tls = 1;
- getTlsFieldBuilder() - Method in class io.grpc.channelz.v1.Security.Builder
-
.grpc.channelz.v1.Security.Tls tls = 1;
- getTlsOrBuilder() - Method in class io.grpc.channelz.v1.Security.Builder
-
.grpc.channelz.v1.Security.Tls tls = 1;
- getTlsOrBuilder() - Method in class io.grpc.channelz.v1.Security
-
.grpc.channelz.v1.Security.Tls tls = 1;
- getTlsOrBuilder() - Method in interface io.grpc.channelz.v1.SecurityOrBuilder
-
.grpc.channelz.v1.Security.Tls tls = 1;
- getToken() - Method in class io.grpc.grpclb.BackendAddressGroup
- getTopChannels(GetTopChannelsRequest) - Method in class io.grpc.channelz.v1.ChannelzGrpc.ChannelzBlockingStub
-
Gets all root channels (i.e.
- getTopChannels(GetTopChannelsRequest) - Method in class io.grpc.channelz.v1.ChannelzGrpc.ChannelzFutureStub
-
Gets all root channels (i.e.
- getTopChannels(GetTopChannelsRequest, StreamObserver<GetTopChannelsResponse>) - Method in interface io.grpc.channelz.v1.ChannelzGrpc.AsyncService
-
Gets all root channels (i.e.
- getTopChannels(GetTopChannelsRequest, StreamObserver<GetTopChannelsResponse>) - Method in class io.grpc.channelz.v1.ChannelzGrpc.ChannelzStub
-
Gets all root channels (i.e.
- getTopChannels(GetTopChannelsRequest, StreamObserver<GetTopChannelsResponse>) - Method in class io.grpc.protobuf.services.ChannelzService
-
Returns top level channel aka
ManagedChannel
. - getTopChannels(GetTopChannelsRequest, StreamObserver<GetTopChannelsResponse>) - Method in class io.grpc.services.ChannelzService
-
Deprecated.Returns top level channel aka
ManagedChannel
. - GetTopChannelsRequest - Class in io.grpc.channelz.v1
-
Protobuf type
grpc.channelz.v1.GetTopChannelsRequest
- GetTopChannelsRequest() - Constructor for class io.grpc.channelz.v1.GetTopChannelsRequest
- GetTopChannelsRequest(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.channelz.v1.GetTopChannelsRequest
- GetTopChannelsRequest.Builder - Class in io.grpc.channelz.v1
-
Protobuf type
grpc.channelz.v1.GetTopChannelsRequest
- GetTopChannelsRequestOrBuilder - Interface in io.grpc.channelz.v1
- GetTopChannelsResponse - Class in io.grpc.channelz.v1
-
Protobuf type
grpc.channelz.v1.GetTopChannelsResponse
- GetTopChannelsResponse() - Constructor for class io.grpc.channelz.v1.GetTopChannelsResponse
- GetTopChannelsResponse(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.channelz.v1.GetTopChannelsResponse
- GetTopChannelsResponse.Builder - Class in io.grpc.channelz.v1
-
Protobuf type
grpc.channelz.v1.GetTopChannelsResponse
- GetTopChannelsResponseOrBuilder - Interface in io.grpc.channelz.v1
- getTrace() - Method in class io.grpc.channelz.v1.ChannelData.Builder
-
A trace of recent events on the channel.
- getTrace() - Method in class io.grpc.channelz.v1.ChannelData
-
A trace of recent events on the channel.
- getTrace() - Method in interface io.grpc.channelz.v1.ChannelDataOrBuilder
-
A trace of recent events on the channel.
- getTrace() - Method in class io.grpc.channelz.v1.ServerData.Builder
-
A trace of recent events on the server.
- getTrace() - Method in class io.grpc.channelz.v1.ServerData
-
A trace of recent events on the server.
- getTrace() - Method in interface io.grpc.channelz.v1.ServerDataOrBuilder
-
A trace of recent events on the server.
- getTraceBuilder() - Method in class io.grpc.channelz.v1.ChannelData.Builder
-
A trace of recent events on the channel.
- getTraceBuilder() - Method in class io.grpc.channelz.v1.ServerData.Builder
-
A trace of recent events on the server.
- getTraceFieldBuilder() - Method in class io.grpc.channelz.v1.ChannelData.Builder
-
A trace of recent events on the channel.
- getTraceFieldBuilder() - Method in class io.grpc.channelz.v1.ServerData.Builder
-
A trace of recent events on the server.
- getTraceOrBuilder() - Method in class io.grpc.channelz.v1.ChannelData.Builder
-
A trace of recent events on the channel.
- getTraceOrBuilder() - Method in class io.grpc.channelz.v1.ChannelData
-
A trace of recent events on the channel.
- getTraceOrBuilder() - Method in interface io.grpc.channelz.v1.ChannelDataOrBuilder
-
A trace of recent events on the channel.
- getTraceOrBuilder() - Method in class io.grpc.channelz.v1.ServerData.Builder
-
A trace of recent events on the server.
- getTraceOrBuilder() - Method in class io.grpc.channelz.v1.ServerData
-
A trace of recent events on the server.
- getTraceOrBuilder() - Method in interface io.grpc.channelz.v1.ServerDataOrBuilder
-
A trace of recent events on the server.
- getTracerFactories() - Method in class io.grpc.internal.ServerImplBuilder
- getTracersForTest() - Method in class io.grpc.internal.StatsTraceContext
-
Returns a copy of the tracer list.
- getTrailer() - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
.grpc.binarylog.v1.Trailer trailer = 9;
- getTrailer() - Method in class io.grpc.binarylog.v1.GrpcLogEntry
-
.grpc.binarylog.v1.Trailer trailer = 9;
- getTrailer() - Method in interface io.grpc.binarylog.v1.GrpcLogEntryOrBuilder
-
.grpc.binarylog.v1.Trailer trailer = 9;
- getTrailerBuilder() - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
.grpc.binarylog.v1.Trailer trailer = 9;
- getTrailerFieldBuilder() - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
.grpc.binarylog.v1.Trailer trailer = 9;
- getTrailerOrBuilder() - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
.grpc.binarylog.v1.Trailer trailer = 9;
- getTrailerOrBuilder() - Method in class io.grpc.binarylog.v1.GrpcLogEntry
-
.grpc.binarylog.v1.Trailer trailer = 9;
- getTrailerOrBuilder() - Method in interface io.grpc.binarylog.v1.GrpcLogEntryOrBuilder
-
.grpc.binarylog.v1.Trailer trailer = 9;
- getTrailers() - Method in exception class io.grpc.StatusException
-
Returns the received trailers.
- getTrailers() - Method in exception class io.grpc.StatusRuntimeException
-
Returns the received trailers.
- getTransport() - Method in class io.grpc.internal.InternalSubchannel
-
Returns a READY transport if there is any, without trying to connect.
- getTransportAttrs() - Method in class io.grpc.CallCredentials.RequestInfo
-
Returns the transport attributes.
- getTransportFromPickResult(LoadBalancer.PickResult, boolean) - Static method in class io.grpc.internal.GrpcUtil
-
Returns a transport out of a PickResult, or
null
if the result is "buffer". - getTransportTracer() - Method in class io.grpc.internal.AbstractClientStream
- getTransportTracer() - Method in class io.grpc.internal.AbstractStream.TransportState
- getTrustDomain() - Method in class io.grpc.internal.SpiffeUtil.SpiffeId
- getTrustManagers() - Method in class io.grpc.TlsChannelCredentials
-
Returns the trust manager list which verifies the server's identity.
- getTrustManagers() - Method in class io.grpc.TlsServerCredentials
-
Returns the trust manager list which verifies the client's identity.
- getType() - Method in class io.grpc.binarylog.v1.Address.Builder
-
.grpc.binarylog.v1.Address.Type type = 1;
- getType() - Method in class io.grpc.binarylog.v1.Address
-
.grpc.binarylog.v1.Address.Type type = 1;
- getType() - Method in interface io.grpc.binarylog.v1.AddressOrBuilder
-
.grpc.binarylog.v1.Address.Type type = 1;
- getType() - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
.grpc.binarylog.v1.GrpcLogEntry.EventType type = 4;
- getType() - Method in class io.grpc.binarylog.v1.GrpcLogEntry
-
.grpc.binarylog.v1.GrpcLogEntry.EventType type = 4;
- getType() - Method in interface io.grpc.binarylog.v1.GrpcLogEntryOrBuilder
-
.grpc.binarylog.v1.GrpcLogEntry.EventType type = 4;
- getType() - Method in class io.grpc.MethodDescriptor
-
The call type of the method.
- getTypeName() - Method in class io.grpc.InternalLogId
- getTypeValue() - Method in class io.grpc.binarylog.v1.Address.Builder
-
.grpc.binarylog.v1.Address.Type type = 1;
- getTypeValue() - Method in class io.grpc.binarylog.v1.Address
-
.grpc.binarylog.v1.Address.Type type = 1;
- getTypeValue() - Method in interface io.grpc.binarylog.v1.AddressOrBuilder
-
.grpc.binarylog.v1.Address.Type type = 1;
- getTypeValue() - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
.grpc.binarylog.v1.GrpcLogEntry.EventType type = 4;
- getTypeValue() - Method in class io.grpc.binarylog.v1.GrpcLogEntry
-
.grpc.binarylog.v1.GrpcLogEntry.EventType type = 4;
- getTypeValue() - Method in interface io.grpc.binarylog.v1.GrpcLogEntryOrBuilder
-
.grpc.binarylog.v1.GrpcLogEntry.EventType type = 4;
- getUdsAddress() - Method in class io.grpc.channelz.v1.Address.Builder
-
.grpc.channelz.v1.Address.UdsAddress uds_address = 2;
- getUdsAddress() - Method in class io.grpc.channelz.v1.Address
-
.grpc.channelz.v1.Address.UdsAddress uds_address = 2;
- getUdsAddress() - Method in interface io.grpc.channelz.v1.AddressOrBuilder
-
.grpc.channelz.v1.Address.UdsAddress uds_address = 2;
- getUdsAddressBuilder() - Method in class io.grpc.channelz.v1.Address.Builder
-
.grpc.channelz.v1.Address.UdsAddress uds_address = 2;
- getUdsAddressFieldBuilder() - Method in class io.grpc.channelz.v1.Address.Builder
-
.grpc.channelz.v1.Address.UdsAddress uds_address = 2;
- getUdsAddressOrBuilder() - Method in class io.grpc.channelz.v1.Address.Builder
-
.grpc.channelz.v1.Address.UdsAddress uds_address = 2;
- getUdsAddressOrBuilder() - Method in class io.grpc.channelz.v1.Address
-
.grpc.channelz.v1.Address.UdsAddress uds_address = 2;
- getUdsAddressOrBuilder() - Method in interface io.grpc.channelz.v1.AddressOrBuilder
-
.grpc.channelz.v1.Address.UdsAddress uds_address = 2;
- getUnchecked(Future<V>) - Static method in class io.grpc.stub.ClientCalls
-
Returns the result of calling
Future.get()
interruptibly on a task known not to throw a checked exception. - getUncompressedBody() - Method in class io.grpc.internal.MessageDeframer
- getUnit() - Method in interface io.grpc.MetricInstrument
-
Returns the unit of measurement for the metric.
- getUnit() - Method in class io.grpc.PartialMetricInstrument
- getUnsafeChannelCredentials() - Method in class io.grpc.internal.ManagedChannelImpl.LbHelperImpl
- getUnsafeChannelCredentials() - Method in class io.grpc.LoadBalancer.Helper
-
Returns the UNSAFE ChannelCredentials used to construct the channel, including bearer tokens.
- getUnsafeChannelCredentials() - Method in class io.grpc.util.ForwardingLoadBalancerHelper
- getUserAgent() - Method in class io.grpc.internal.ClientTransportFactory.ClientTransportOptions
- getUserAgent() - Method in class io.grpc.internal.GrpcUtil.GrpcBuildVersion
- getUsername() - Method in class io.grpc.HttpConnectProxiedSocketAddress
-
Returns the username used to connect to the proxy.
- getUtilizationMetrics() - Method in class io.grpc.services.MetricReport
- getValidHost() - Method in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
-
string valid_host = 1;
- getValidHost() - Method in class io.grpc.reflection.v1.ServerReflectionResponse
-
string valid_host = 1;
- getValidHost() - Method in interface io.grpc.reflection.v1.ServerReflectionResponseOrBuilder
-
string valid_host = 1;
- getValidHost() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
-
string valid_host = 1;
- getValidHost() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse
-
string valid_host = 1;
- getValidHost() - Method in interface io.grpc.reflection.v1alpha.ServerReflectionResponseOrBuilder
-
string valid_host = 1;
- getValidHostBytes() - Method in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
-
string valid_host = 1;
- getValidHostBytes() - Method in class io.grpc.reflection.v1.ServerReflectionResponse
-
string valid_host = 1;
- getValidHostBytes() - Method in interface io.grpc.reflection.v1.ServerReflectionResponseOrBuilder
-
string valid_host = 1;
- getValidHostBytes() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
-
string valid_host = 1;
- getValidHostBytes() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse
-
string valid_host = 1;
- getValidHostBytes() - Method in interface io.grpc.reflection.v1alpha.ServerReflectionResponseOrBuilder
-
string valid_host = 1;
- getValidTargets(int) - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
This is a list of all the possible targets that can be returned by the lookup service.
- getValidTargets(int) - Method in class io.grpc.lookup.v1.RouteLookupConfig
-
This is a list of all the possible targets that can be returned by the lookup service.
- getValidTargets(int) - Method in interface io.grpc.lookup.v1.RouteLookupConfigOrBuilder
-
This is a list of all the possible targets that can be returned by the lookup service.
- getValidTargetsBytes(int) - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
This is a list of all the possible targets that can be returned by the lookup service.
- getValidTargetsBytes(int) - Method in class io.grpc.lookup.v1.RouteLookupConfig
-
This is a list of all the possible targets that can be returned by the lookup service.
- getValidTargetsBytes(int) - Method in interface io.grpc.lookup.v1.RouteLookupConfigOrBuilder
-
This is a list of all the possible targets that can be returned by the lookup service.
- getValidTargetsCount() - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
This is a list of all the possible targets that can be returned by the lookup service.
- getValidTargetsCount() - Method in class io.grpc.lookup.v1.RouteLookupConfig
-
This is a list of all the possible targets that can be returned by the lookup service.
- getValidTargetsCount() - Method in interface io.grpc.lookup.v1.RouteLookupConfigOrBuilder
-
This is a list of all the possible targets that can be returned by the lookup service.
- getValidTargetsList() - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
This is a list of all the possible targets that can be returned by the lookup service.
- getValidTargetsList() - Method in class io.grpc.lookup.v1.RouteLookupConfig
-
This is a list of all the possible targets that can be returned by the lookup service.
- getValidTargetsList() - Method in interface io.grpc.lookup.v1.RouteLookupConfigOrBuilder
-
This is a list of all the possible targets that can be returned by the lookup service.
- getValue() - Method in class io.grpc.binarylog.v1.MetadataEntry.Builder
-
bytes value = 2;
- getValue() - Method in class io.grpc.binarylog.v1.MetadataEntry
-
bytes value = 2;
- getValue() - Method in interface io.grpc.binarylog.v1.MetadataEntryOrBuilder
-
bytes value = 2;
- getValue() - Method in class io.grpc.channelz.v1.Address.OtherAddress.Builder
-
The actual address message.
- getValue() - Method in class io.grpc.channelz.v1.Address.OtherAddress
-
The actual address message.
- getValue() - Method in interface io.grpc.channelz.v1.Address.OtherAddressOrBuilder
-
The actual address message.
- getValue() - Method in class io.grpc.channelz.v1.Security.OtherSecurity.Builder
-
The actual security details message.
- getValue() - Method in class io.grpc.channelz.v1.Security.OtherSecurity
-
The actual security details message.
- getValue() - Method in interface io.grpc.channelz.v1.Security.OtherSecurityOrBuilder
-
The actual security details message.
- getValue() - Method in class io.grpc.channelz.v1.SocketOption.Builder
-
The human readable value of this socket option.
- getValue() - Method in class io.grpc.channelz.v1.SocketOption
-
The human readable value of this socket option.
- getValue() - Method in interface io.grpc.channelz.v1.SocketOptionOrBuilder
-
The human readable value of this socket option.
- getValue() - Method in class io.grpc.netty.GrpcHttp2OutboundHeaders.Itr
- getValue() - Method in class io.grpc.StatusOr
-
Returns the value if set or throws exception if there is no value set.
- getValueBuilder() - Method in class io.grpc.channelz.v1.Address.OtherAddress.Builder
-
The actual address message.
- getValueBuilder() - Method in class io.grpc.channelz.v1.Security.OtherSecurity.Builder
-
The actual security details message.
- getValueBytes() - Method in class io.grpc.channelz.v1.SocketOption.Builder
-
The human readable value of this socket option.
- getValueBytes() - Method in class io.grpc.channelz.v1.SocketOption
-
The human readable value of this socket option.
- getValueBytes() - Method in interface io.grpc.channelz.v1.SocketOptionOrBuilder
-
The human readable value of this socket option.
- getValueDescriptor() - Method in enum io.grpc.binarylog.v1.Address.Type
- getValueDescriptor() - Method in enum io.grpc.binarylog.v1.GrpcLogEntry.EventType
- getValueDescriptor() - Method in enum io.grpc.binarylog.v1.GrpcLogEntry.Logger
- getValueDescriptor() - Method in enum io.grpc.channelz.v1.ChannelConnectivityState.State
- getValueDescriptor() - Method in enum io.grpc.channelz.v1.ChannelTraceEvent.Severity
- getValueDescriptor() - Method in enum io.grpc.health.v1.HealthCheckResponse.ServingStatus
- getValueDescriptor() - Method in enum io.grpc.lookup.v1.RouteLookupRequest.Reason
- getValueFieldBuilder() - Method in class io.grpc.channelz.v1.Address.OtherAddress.Builder
-
The actual address message.
- getValueFieldBuilder() - Method in class io.grpc.channelz.v1.Security.OtherSecurity.Builder
-
The actual security details message.
- getValueOrBuilder() - Method in class io.grpc.channelz.v1.Address.OtherAddress.Builder
-
The actual address message.
- getValueOrBuilder() - Method in class io.grpc.channelz.v1.Address.OtherAddress
-
The actual address message.
- getValueOrBuilder() - Method in interface io.grpc.channelz.v1.Address.OtherAddressOrBuilder
-
The actual address message.
- getValueOrBuilder() - Method in class io.grpc.channelz.v1.Security.OtherSecurity.Builder
-
The actual security details message.
- getValueOrBuilder() - Method in class io.grpc.channelz.v1.Security.OtherSecurity
-
The actual security details message.
- getValueOrBuilder() - Method in interface io.grpc.channelz.v1.Security.OtherSecurityOrBuilder
-
The actual security details message.
- getWaitForReady() - Method in class io.grpc.CallOptions
- getWaitForReady(CallOptions) - Static method in class io.grpc.InternalCallOptions
-
Gets the waitForReady bit or
null
if it was never set. - getWaitForReadyFromMethodConfig(Map<String, ?>) - Static method in class io.grpc.internal.ServiceConfigUtil
- getWatchMethod - Static variable in class io.grpc.health.v1.HealthGrpc
- getWatchMethod() - Static method in class io.grpc.health.v1.HealthGrpc
- getWriteQueue() - Method in class io.grpc.netty.NettyClientHandler
- getWriteQueue() - Method in class io.grpc.netty.NettyServerHandler
- getX509Certificates(InputStream) - Static method in class io.grpc.util.CertificateUtils
-
Generates X509Certificate array from a PEM file.
- globalLog - Variable in class io.grpc.protobuf.services.BinlogHelper.FactoryImpl
- globalRegistry - Static variable in class io.grpc.protobuf.lite.ProtoLiteUtils
- goAwayDebugString - Variable in class io.grpc.netty.GracefulServerCloseCommand
- goAwayMessage - Variable in class io.grpc.netty.NettyServerHandler.GracefulShutdown
- goingAway(long, byte[]) - Method in class io.grpc.netty.NettyClientHandler
-
Handler for a GOAWAY being received.
- gotoNonErrorState(ConnectivityState) - Method in class io.grpc.internal.InternalSubchannel
- gotoState(ConnectivityState) - Method in class io.grpc.internal.ConnectivityStateManager
-
Connectivity state is changed to the specified value.
- gotoState(ConnectivityStateInfo) - Method in class io.grpc.internal.InternalSubchannel
- gotoState(ConnectivityStateInfo) - Method in class io.grpc.protobuf.services.HealthCheckingLoadBalancerFactory.HealthCheckState
- GRACEFUL_SHUTDOWN_NO_TIMEOUT - Static variable in class io.grpc.netty.AbstractNettyHandler
- GRACEFUL_SHUTDOWN_PING - Static variable in class io.grpc.netty.NettyServerHandler
- GRACEFUL_SHUTDOWN_PING_TIMEOUT_NANOS - Static variable in class io.grpc.netty.NettyServerHandler
- gracefulClose(ChannelHandlerContext, GracefulCloseCommand, ChannelPromise) - Method in class io.grpc.netty.NettyClientHandler
- gracefulClose(ChannelHandlerContext, GracefulServerCloseCommand, ChannelPromise) - Method in class io.grpc.netty.NettyServerHandler
- GracefulCloseCommand - Class in io.grpc.netty
-
A command to trigger close.
- GracefulCloseCommand(Status) - Constructor for class io.grpc.netty.GracefulCloseCommand
- GracefulServerCloseCommand - Class in io.grpc.netty
-
A command to trigger close and allow streams naturally close.
- GracefulServerCloseCommand(String) - Constructor for class io.grpc.netty.GracefulServerCloseCommand
- GracefulServerCloseCommand(String, long, TimeUnit) - Constructor for class io.grpc.netty.GracefulServerCloseCommand
- gracefulShutdown - Variable in class io.grpc.netty.NettyServerHandler
- GracefulShutdown(String, Long) - Constructor for class io.grpc.netty.NettyServerHandler.GracefulShutdown
- GracefulSwitchLoadBalancer - Class in io.grpc.util
-
A load balancer that gracefully swaps to a new lb policy.
- GracefulSwitchLoadBalancer(LoadBalancer.Helper) - Constructor for class io.grpc.util.GracefulSwitchLoadBalancer
- GracefulSwitchLoadBalancer.Config - Class in io.grpc.util
- graceTime - Variable in class io.grpc.netty.GracefulServerCloseCommand
- graceTimeInNanos - Variable in class io.grpc.netty.NettyServerHandler.GracefulShutdown
-
The grace time between starting graceful shutdown and closing the netty channel,
null
is unspecified. - graceTimeOverrideMillis(long) - Method in class io.grpc.netty.NettyServerHandler.GracefulShutdown
- graceTimeUnit - Variable in class io.grpc.netty.GracefulServerCloseCommand
- group - Variable in class io.grpc.netty.NettyChannelBuilder.NettyTransportFactory
- group - Variable in class io.grpc.netty.NettyClientTransport
- groupIndex - Variable in class io.grpc.internal.InternalSubchannel.Index
- groupIndex - Variable in class io.grpc.internal.PickFirstLeafLoadBalancer.Index
- groupPool - Variable in class io.grpc.netty.NettyChannelBuilder.NettyTransportFactory
- 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() - Constructor for class io.grpc.Grpc
- GRPC_KEYBUILDERS_FIELD_NUMBER - Static variable in class io.grpc.lookup.v1.RouteLookupConfig
- GRPC_PF_USE_HAPPY_EYEBALLS - Static variable in class io.grpc.internal.PickFirstLoadBalancerProvider
- GRPC_PREVIOUS_RPC_ATTEMPTS - Static variable in class io.grpc.internal.RetriableStream
- GRPC_PROXY_ENV_VAR - Static variable in class io.grpc.internal.ProxyDetectorImpl
-
Deprecated.Use the standard Java proxy configuration instead with flags such as: -Dhttps.proxyHost=HOST -Dhttps.proxyPort=PORT
- GRPC_RETRY_PUSHBACK_MS - Static variable in class io.grpc.internal.RetriableStream
- Grpc.TransportAttr - Annotation Type in io.grpc
-
Annotation for transport attributes.
- GrpcAsyncListener(ServletServerStream, InternalLogId) - Constructor for class io.grpc.servlet.jakarta.ServletAdapter.GrpcAsyncListener
- GrpcAsyncListener(ServletServerStream, InternalLogId) - Constructor for class io.grpc.servlet.ServletAdapter.GrpcAsyncListener
- GrpcAttributes - Class in io.grpc.internal
-
Special attributes that are only useful to gRPC.
- GrpcAttributes() - Constructor for class io.grpc.internal.GrpcAttributes
- GrpcBuildVersion(String, String) - Constructor for class io.grpc.internal.GrpcUtil.GrpcBuildVersion
- GrpcFuture(ClientCall<?, RespT>) - Constructor for class io.grpc.stub.ClientCalls.GrpcFuture
- GrpcGenerated - Annotation Type in io.grpc.stub.annotations
-
Annotates that the class is gRPC-generated code to assist Java Annotation Processors.
- grpcHandler - Variable in class io.grpc.netty.NettyServerTransport
- GrpcHttp2ClientHeadersDecoder(long) - Constructor for class io.grpc.netty.GrpcHttp2HeadersUtils.GrpcHttp2ClientHeadersDecoder
- GrpcHttp2ConnectionHandler - Class in io.grpc.netty
-
gRPC wrapper for
Http2ConnectionHandler
. - GrpcHttp2ConnectionHandler(ChannelPromise, Http2ConnectionDecoder, Http2ConnectionEncoder, Http2Settings, ChannelLogger) - Constructor for class io.grpc.netty.GrpcHttp2ConnectionHandler
- GrpcHttp2HeadersUtils - Class in io.grpc.netty
-
A headers utils providing custom gRPC implementations of
DefaultHttp2HeadersDecoder
. - GrpcHttp2HeadersUtils() - Constructor for class io.grpc.netty.GrpcHttp2HeadersUtils
- GrpcHttp2HeadersUtils.GrpcHttp2ClientHeadersDecoder - Class in io.grpc.netty
- GrpcHttp2HeadersUtils.GrpcHttp2InboundHeaders - Class in io.grpc.netty
-
A
Http2Headers
implementation optimized for inbound/received headers. - GrpcHttp2HeadersUtils.GrpcHttp2RequestHeaders - Class in io.grpc.netty
-
A
GrpcHttp2HeadersUtils.GrpcHttp2InboundHeaders
implementation, optimized for HTTP/2 request headers. - GrpcHttp2HeadersUtils.GrpcHttp2ResponseHeaders - Class in io.grpc.netty
-
This class only implements the methods used by
NettyClientHandler
and tests. - GrpcHttp2HeadersUtils.GrpcHttp2ServerHeadersDecoder - Class in io.grpc.netty
- GrpcHttp2InboundHeaders(int) - Constructor for class io.grpc.netty.GrpcHttp2HeadersUtils.GrpcHttp2InboundHeaders
- GrpcHttp2OutboundHeaders - Class in io.grpc.netty
-
A custom implementation of Http2Headers that only includes methods used by gRPC.
- GrpcHttp2OutboundHeaders(AsciiString[], byte[][]) - Constructor for class io.grpc.netty.GrpcHttp2OutboundHeaders
- GrpcHttp2OutboundHeaders.Itr - Class in io.grpc.netty
- GrpcHttp2RequestHeaders(int) - Constructor for class io.grpc.netty.GrpcHttp2HeadersUtils.GrpcHttp2RequestHeaders
- GrpcHttp2ResponseHeaders(int) - Constructor for class io.grpc.netty.GrpcHttp2HeadersUtils.GrpcHttp2ResponseHeaders
- GrpcHttp2ServerHeadersDecoder(long) - Constructor for class io.grpc.netty.GrpcHttp2HeadersUtils.GrpcHttp2ServerHeadersDecoder
- GrpcKeyBuilder - Class in io.grpc.lookup.v1
-
A GrpcKeyBuilder applies to a given gRPC service, name, and headers.
- GrpcKeyBuilder() - Constructor for class io.grpc.lookup.v1.GrpcKeyBuilder
- GrpcKeyBuilder() - Constructor for class io.grpc.rls.RlsProtoData.GrpcKeyBuilder
- GrpcKeyBuilder(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.lookup.v1.GrpcKeyBuilder
- GrpcKeyBuilder.Builder - Class in io.grpc.lookup.v1
-
A GrpcKeyBuilder applies to a given gRPC service, name, and headers.
- GrpcKeyBuilder.ConstantKeysDefaultEntryHolder - Class in io.grpc.lookup.v1
- GrpcKeyBuilder.ExtraKeys - Class in io.grpc.lookup.v1
-
If you wish to include the host, service, or method names as keys in the generated RouteLookupRequest, specify key names to use in the extra_keys submessage.
- GrpcKeyBuilder.ExtraKeys.Builder - Class in io.grpc.lookup.v1
-
If you wish to include the host, service, or method names as keys in the generated RouteLookupRequest, specify key names to use in the extra_keys submessage.
- GrpcKeyBuilder.ExtraKeysOrBuilder - Interface in io.grpc.lookup.v1
- GrpcKeyBuilder.Name - Class in io.grpc.lookup.v1
-
To match, one of the given Name fields must match; the service and method fields are specified as fixed strings.
- GrpcKeyBuilder.Name.Builder - Class in io.grpc.lookup.v1
-
To match, one of the given Name fields must match; the service and method fields are specified as fixed strings.
- GrpcKeyBuilder.NameOrBuilder - Interface in io.grpc.lookup.v1
- GrpcKeyBuilderConverter() - Constructor for class io.grpc.rls.RlsProtoConverters.GrpcKeyBuilderConverter
- GrpcKeyBuilderOrBuilder - Interface in io.grpc.lookup.v1
- grpcKeybuilders - Variable in class io.grpc.rls.AutoValue_RlsProtoData_RouteLookupConfig.Builder
- grpcKeybuilders - Variable in class io.grpc.rls.AutoValue_RlsProtoData_RouteLookupConfig
- grpcKeybuilders() - Method in class io.grpc.rls.AutoValue_RlsProtoData_RouteLookupConfig
- grpcKeybuilders() - Method in class io.grpc.rls.RlsProtoData.RouteLookupConfig
-
Returns unordered specifications for constructing keys for gRPC requests.
- grpcKeybuilders(ImmutableList<RlsProtoData.GrpcKeyBuilder>) - Method in class io.grpc.rls.AutoValue_RlsProtoData_RouteLookupConfig.Builder
- grpcKeybuilders(ImmutableList<RlsProtoData.GrpcKeyBuilder>) - Method in class io.grpc.rls.RlsProtoData.RouteLookupConfig.Builder
- grpcKeybuilders_ - Variable in class io.grpc.lookup.v1.RouteLookupConfig.Builder
- grpcKeybuilders_ - Variable in class io.grpc.lookup.v1.RouteLookupConfig
- grpcKeybuildersBuilder_ - Variable in class io.grpc.lookup.v1.RouteLookupConfig.Builder
- GRPCLB_NAME_PREFIX - Static variable in class io.grpc.grpclb.GrpclbNameResolver
- GrpclbClientLoadRecorder - Class in io.grpc.grpclb
-
Record and aggregate client-side load data for GRPCLB.
- GrpclbClientLoadRecorder(TimeProvider) - Constructor for class io.grpc.grpclb.GrpclbClientLoadRecorder
- GrpclbClientLoadRecorder.LongHolder - Class in io.grpc.grpclb
- GrpclbClientLoadRecorder.StreamTracer - Class in io.grpc.grpclb
- GrpclbConfig - Class in io.grpc.grpclb
- GrpclbConfig(GrpclbState.Mode, String, long) - Constructor for class io.grpc.grpclb.GrpclbConfig
- GrpclbConstants - Class in io.grpc.grpclb
-
Constants for the GRPCLB load-balancer.
- GrpclbConstants() - Constructor for class io.grpc.grpclb.GrpclbConstants
- GrpclbLoadBalancer - Class in io.grpc.grpclb
-
A
LoadBalancer
that uses the GRPCLB protocol. - GrpclbLoadBalancer(LoadBalancer.Helper, Context, SubchannelPool, TimeProvider, Stopwatch, BackoffPolicy.Provider) - Constructor for class io.grpc.grpclb.GrpclbLoadBalancer
- GrpclbLoadBalancerProvider - Class in io.grpc.grpclb
-
The provider for the "grpclb" balancing policy.
- GrpclbLoadBalancerProvider() - Constructor for class io.grpc.grpclb.GrpclbLoadBalancerProvider
- GrpclbNameResolver - Class in io.grpc.grpclb
-
A DNS-based
NameResolver
with gRPC LB specific add-ons for resolving balancer addresses via service records. - GrpclbNameResolver(String, String, NameResolver.Args, SharedResourceHolder.Resource<Executor>, Stopwatch, boolean) - Constructor for class io.grpc.grpclb.GrpclbNameResolver
- grpclbState - Variable in class io.grpc.grpclb.GrpclbLoadBalancer
- GrpclbState - Class in io.grpc.grpclb
-
The states of a GRPCLB working session of
GrpclbLoadBalancer
. - GrpclbState(GrpclbConfig, LoadBalancer.Helper, Context, SubchannelPool, TimeProvider, Stopwatch, BackoffPolicy.Provider) - Constructor for class io.grpc.grpclb.GrpclbState
- GrpclbState.BackendEntry - Class in io.grpc.grpclb
- GrpclbState.DropEntry - Class in io.grpc.grpclb
- GrpclbState.ErrorEntry - Class in io.grpc.grpclb
- GrpclbState.FallbackModeTask - Class in io.grpc.grpclb
- GrpclbState.IdleSubchannelEntry - Class in io.grpc.grpclb
- GrpclbState.LbRpcRetryTask - Class in io.grpc.grpclb
- GrpclbState.LbStream - Class in io.grpc.grpclb
- GrpclbState.LoadReportingTask - Class in io.grpc.grpclb
- GrpclbState.Mode - Enum in io.grpc.grpclb
- GrpclbState.RoundRobinEntry - Interface in io.grpc.grpclb
- GrpclbState.RoundRobinPicker - Class in io.grpc.grpclb
- GrpcLogEntry - Class in io.grpc.binarylog.v1
-
Log entry we store in binary logs
- GrpcLogEntry() - Constructor for class io.grpc.binarylog.v1.GrpcLogEntry
- GrpcLogEntry(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.binarylog.v1.GrpcLogEntry
- GrpcLogEntry.Builder - Class in io.grpc.binarylog.v1
-
Log entry we store in binary logs
- GrpcLogEntry.EventType - Enum in io.grpc.binarylog.v1
-
Enumerates the type of event Note the terminology is different from the RPC semantics definition, but the same meaning is expressed here.
- GrpcLogEntry.Logger - Enum in io.grpc.binarylog.v1
-
Enumerates the entity that generates the log entry
- GrpcLogEntry.PayloadCase - Enum in io.grpc.binarylog.v1
- GrpcLogEntryOrBuilder - Interface in io.grpc.binarylog.v1
- grpcNegotiationHandler(GrpcHttp2ConnectionHandler) - Static method in class io.grpc.netty.InternalProtocolNegotiators
-
Internal version of
ProtocolNegotiators.GrpcNegotiationHandler
. - GrpcNegotiationHandler(GrpcHttp2ConnectionHandler) - Constructor for class io.grpc.netty.ProtocolNegotiators.GrpcNegotiationHandler
- GrpcReadListener(ServletServerStream, AsyncContext, InternalLogId) - Constructor for class io.grpc.servlet.jakarta.ServletAdapter.GrpcReadListener
- GrpcReadListener(ServletServerStream, AsyncContext, InternalLogId) - Constructor for class io.grpc.servlet.ServletAdapter.GrpcReadListener
- GrpcServlet - Class in io.grpc.servlet
-
A simple servlet backed by a gRPC server.
- GrpcServlet - Class in io.grpc.servlet.jakarta
-
A simple servlet backed by a gRPC server.
- GrpcServlet(ServletAdapter) - Constructor for class io.grpc.servlet.jakarta.GrpcServlet
- GrpcServlet(ServletAdapter) - Constructor for class io.grpc.servlet.GrpcServlet
- GrpcServlet(List<? extends BindableService>) - Constructor for class io.grpc.servlet.GrpcServlet
-
Instantiate the servlet serving the given list of gRPC services.
- GrpcServlet(List<? extends BindableService>) - Constructor for class io.grpc.servlet.jakarta.GrpcServlet
-
Instantiate the servlet serving the given list of gRPC services.
- GrpcSslContexts - Class in io.grpc.netty
-
Utility for configuring SslContext for gRPC.
- GrpcSslContexts() - Constructor for class io.grpc.netty.GrpcSslContexts
- GrpcSslContexts.ConscryptHolder - Class in io.grpc.netty
- GrpcUtil - Class in io.grpc.internal
-
Common utilities for GRPC.
- GrpcUtil() - Constructor for class io.grpc.internal.GrpcUtil
- GrpcUtil.AcceptEncodingMarshaller - Class in io.grpc.internal
- GrpcUtil.AuthorityEscaper - Class in io.grpc.internal
-
Percent encode the
authority
based on https://datatracker.ietf.org/doc/html/rfc3986#section-3.2. - GrpcUtil.GrpcBuildVersion - Class in io.grpc.internal
- GrpcUtil.Http2Error - Enum in io.grpc.internal
-
All error codes identified by the HTTP/2 spec.
- GrpcUtil.TimeoutMarshaller - Class in io.grpc.internal
-
Marshals a nanoseconds representation of the timeout to and from a string representation, consisting of an ASCII decimal representation of a number with at most 8 digits, followed by a unit.
- GrpcWriteListener() - Constructor for class io.grpc.servlet.jakarta.ServletServerStream.GrpcWriteListener
- GrpcWriteListener() - Constructor for class io.grpc.servlet.ServletServerStream.GrpcWriteListener
- Gzip() - Constructor for class io.grpc.Codec.Gzip
- GZIP_HEADER_MIN_SIZE - Static variable in class io.grpc.internal.GzipInflatingBuffer
- GZIP_MAGIC - Static variable in class io.grpc.internal.GzipInflatingBuffer
- GZIP_TRAILER_SIZE - Static variable in class io.grpc.internal.GzipInflatingBuffer
- gzipHeaderFlag - Variable in class io.grpc.internal.GzipInflatingBuffer
-
Extra state variables for parsing gzip header flags.
- GzipInflatingBuffer - Class in io.grpc.internal
-
Processes gzip streams, delegating to
Inflater
to perform on-demand inflation of the deflated blocks. - GzipInflatingBuffer() - Constructor for class io.grpc.internal.GzipInflatingBuffer
- GzipInflatingBuffer.GzipMetadataReader - Class in io.grpc.internal
-
Reads gzip header and trailer bytes from the inflater's buffer (if bytes beyond the inflate block were given to the inflater) and then from
gzippedData
, and handles updating the CRC and the count of gzipped bytes consumed. - GzipInflatingBuffer.State - Enum in io.grpc.internal
- gzipMetadataReader - Variable in class io.grpc.internal.GzipInflatingBuffer
- GzipMetadataReader() - Constructor for class io.grpc.internal.GzipInflatingBuffer.GzipMetadataReader
- gzippedData - Variable in class io.grpc.internal.GzipInflatingBuffer
-
This buffer holds all input gzipped data, consisting of blocks of deflated data and the surrounding gzip headers and trailers.
H
- halfClose() - Method in class io.grpc.ClientCall
-
Close the call for request message sending.
- halfClose() - Method in class io.grpc.inprocess.InProcessTransport.InProcessStream.InProcessClientStream
- halfClose() - Method in class io.grpc.internal.AbstractClientStream
- halfClose() - Method in class io.grpc.internal.ClientCallImpl
- halfClose() - Method in interface io.grpc.internal.ClientStream
-
Closes the local side of this stream and flushes any remaining messages.
- halfClose() - Method in class io.grpc.internal.DelayedClientCall
- halfClose() - Method in class io.grpc.internal.DelayedStream
- halfClose() - Method in class io.grpc.internal.ForwardingClientStream
- halfClose() - Method in class io.grpc.internal.NoopClientStream
- halfClose() - Method in class io.grpc.internal.RetriableStream
- halfClose() - Method in class io.grpc.PartialForwardingClientCall
- halfCloseCalled - Variable in class io.grpc.internal.ClientCallImpl
- halfClosed - Variable in class io.grpc.stub.ServerCalls.StreamingServerCallHandler.StreamingServerCallListener
- halfClosed() - Method in class io.grpc.internal.ServerCallImpl.ServerStreamListenerImpl
- halfClosed() - Method in class io.grpc.internal.ServerImpl.JumpToApplicationThreadServerStreamListener
- halfClosed() - Method in class io.grpc.internal.ServerImpl.NoopListener
- 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.
- halfCloseInternal() - Method in class io.grpc.internal.ClientCallImpl
- handleAddresses(List<EquivalentAddressGroup>, List<EquivalentAddressGroup>) - Method in class io.grpc.grpclb.GrpclbState
-
Handle new addresses of the balancer and backends from the resolver, and create connection if not yet connected.
- handleErrorInSyncContext(Status) - Method in class io.grpc.internal.ManagedChannelImpl.NameResolverListener
- handleInternalError(Throwable) - Method in class io.grpc.internal.ServerCallImpl
-
Close the
ServerStream
because an internal error occurred. - handleInternalSubchannelState(ConnectivityStateInfo) - Method in class io.grpc.internal.ManagedChannelImpl
- handleInUse() - Method in class io.grpc.internal.InUseStateAggregator
-
Called when the aggregated in-use state has changed to true, which means at least one object is in use.
- handleInUse() - Method in class io.grpc.internal.ManagedChannelImpl.IdleModeStateAggregator
- handleNameResolutionError(Status) - Method in class io.grpc.grpclb.GrpclbLoadBalancer
- handleNameResolutionError(Status) - Method in class io.grpc.internal.AutoConfiguredLoadBalancerFactory.AutoConfiguredLoadBalancer
- handleNameResolutionError(Status) - Method in class io.grpc.internal.AutoConfiguredLoadBalancerFactory.NoopLoadBalancer
- handleNameResolutionError(Status) - Method in class io.grpc.internal.PickFirstLeafLoadBalancer
- handleNameResolutionError(Status) - Method in class io.grpc.internal.PickFirstLoadBalancer
- handleNameResolutionError(Status) - Method in class io.grpc.LoadBalancer
-
Handles an error from the name resolution system.
- handleNameResolutionError(Status) - Method in class io.grpc.rls.RlsLoadBalancer
- handleNameResolutionError(Status) - Method in class io.grpc.util.ForwardingLoadBalancer
- handleNameResolutionError(Status) - Method in class io.grpc.util.MultiChildLoadBalancer
-
Handle the name resolution error.
- handleNameResolutionError(Status) - Method in class io.grpc.util.OutlierDetectionLoadBalancer
- handleNotInUse() - Method in class io.grpc.internal.InUseStateAggregator
-
Called when the aggregated in-use state has changed to false, which means no object is in use.
- handleNotInUse() - Method in class io.grpc.internal.ManagedChannelImpl.IdleModeStateAggregator
- handleOutstandingControlFrames(ChannelHandlerContext, ChannelPromise) - Method in class io.grpc.netty.Http2ControlFrameLimitEncoder
- handleProtocolNegotiationCompleted(Attributes) - Method in class io.grpc.netty.GrpcHttp2ConnectionHandler
-
Deprecated.Use the two argument method instead.
- handleProtocolNegotiationCompleted(Attributes, InternalChannelz.Security) - Method in class io.grpc.netty.GrpcHttp2ConnectionHandler
-
Triggered on protocol negotiation completion.
- handleProtocolNegotiationCompleted(Attributes, InternalChannelz.Security) - Method in class io.grpc.netty.NettyClientHandler
- handleProtocolNegotiationCompleted(Attributes, InternalChannelz.Security) - Method in class io.grpc.netty.NettyServerHandler
- handler - Variable in class io.grpc.netty.NettyClientStream.TransportState
- handler - Variable in class io.grpc.netty.NettyClientTransport
- handler - Variable in class io.grpc.netty.NettyServerStream.TransportState
- handler - Variable in class io.grpc.ServerMethodDefinition
- handlerAdded(ChannelHandlerContext) - Method in class io.grpc.netty.AbstractNettyHandler
- handlerAdded(ChannelHandlerContext) - Method in class io.grpc.netty.NettyServerHandler
- handlerAdded(ChannelHandlerContext) - Method in class io.grpc.netty.ProtocolNegotiators.Http2UpgradeAndGrpcHandler
- handlerAdded(ChannelHandlerContext) - Method in class io.grpc.netty.ProtocolNegotiators.ProtocolNegotiationHandler
- handlerAdded(ChannelHandlerContext) - Method in class io.grpc.netty.ProtocolNegotiators.ServerTlsHandler
- handlerAdded(ChannelHandlerContext) - Method in class io.grpc.netty.WriteBufferingAndExceptionHandler
- handlerAdded0(ChannelHandlerContext) - Method in class io.grpc.netty.ProtocolNegotiators.ClientTlsHandler
- handlerAdded0(ChannelHandlerContext) - Method in class io.grpc.netty.ProtocolNegotiators.ProtocolNegotiationHandler
- handleReflectionRequest() - Method in class io.grpc.protobuf.services.ProtoReflectionServiceV1.ProtoReflectionStreamObserver
- handleResolvedAddresses(LoadBalancer.ResolvedAddresses) - Method in class io.grpc.internal.AutoConfiguredLoadBalancerFactory.NoopLoadBalancer
-
Deprecated.
- handleResolvedAddresses(LoadBalancer.ResolvedAddresses) - Method in class io.grpc.LoadBalancer
-
Handles newly resolved server groups and metadata attributes from name resolution system.
- handleResolvedAddresses(LoadBalancer.ResolvedAddresses) - Method in class io.grpc.protobuf.services.HealthCheckingLoadBalancerFactory.HealthCheckingLoadBalancer
- handleResolvedAddresses(LoadBalancer.ResolvedAddresses) - Method in class io.grpc.util.ForwardingLoadBalancer
- handleResolvedAddresses(LoadBalancer.ResolvedAddresses) - Method in class io.grpc.util.GracefulSwitchLoadBalancer
- handleResponse(HealthCheckResponse) - Method in class io.grpc.protobuf.services.HealthCheckingLoadBalancerFactory.HealthCheckState.HcStream
- handleResponse(LoadBalanceResponse) - Method in class io.grpc.grpclb.GrpclbState.LbStream
- 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
- handlerRemoved(ChannelHandlerContext) - Method in class io.grpc.netty.WriteBufferingAndExceptionHandler
- handleStreamClosed(Status) - Method in class io.grpc.grpclb.GrpclbState.LbStream
- handleStreamClosed(Status) - Method in class io.grpc.protobuf.services.HealthCheckingLoadBalancerFactory.HealthCheckState.HcStream
- handleSubchannelState(LoadBalancer.Subchannel, ConnectivityStateInfo) - Method in class io.grpc.grpclb.GrpclbState
- handleSubchannelState(LoadBalancer.Subchannel, ConnectivityStateInfo) - Method in class io.grpc.internal.AutoConfiguredLoadBalancerFactory.AutoConfiguredLoadBalancer
-
Deprecated.
- handleSubchannelState(LoadBalancer.Subchannel, ConnectivityStateInfo) - Method in class io.grpc.LoadBalancer
-
Deprecated.This method will be removed. Stop overriding it. Instead, pass
LoadBalancer.SubchannelStateListener
toLoadBalancer.Subchannel.start(io.grpc.LoadBalancer.SubchannelStateListener)
to receive Subchannel state updates - handleSubchannelState(LoadBalancer.Subchannel, ConnectivityStateInfo) - Method in class io.grpc.util.ForwardingLoadBalancer
-
Deprecated.
- handleSubchannelState(LoadBalancer.Subchannel, ConnectivityStateInfo) - Method in class io.grpc.util.GracefulSwitchLoadBalancer
-
Deprecated.
- handleSubchannelStateChange(ConnectivityStateInfo) - Method in class io.grpc.internal.OobChannel
- handleSubchannelTerminated() - Method in class io.grpc.internal.OobChannel
- handleTermination() - Method in class io.grpc.internal.InternalSubchannel
- handleTransportInUseState(ConnectionClientTransport, boolean) - Method in class io.grpc.internal.InternalSubchannel
- handleWriteFutureFailures(ChannelFuture) - Method in class io.grpc.netty.NettyServerStream.TransportState
- handshakeCompleteRunnable - Variable in class io.grpc.netty.ProtocolNegotiators.ClientTlsHandler
- handshakeCompleteRunnable - Variable in class io.grpc.netty.ProtocolNegotiators.ClientTlsProtocolNegotiator
- handshakeTimeout(long, TimeUnit) - Method in class io.grpc.ForwardingServerBuilder
- handshakeTimeout(long, TimeUnit) - Method in class io.grpc.internal.ServerImplBuilder
- handshakeTimeout(long, TimeUnit) - Method in class io.grpc.ServerBuilder
-
Sets the permitted time for new connections to complete negotiation handshakes before being killed.
- handshakeTimeoutFuture - Variable in class io.grpc.internal.ServerImpl.ServerTransportListenerImpl
- handshakeTimeoutMillis - Variable in class io.grpc.internal.ServerImpl
- handshakeTimeoutMillis - Variable in class io.grpc.internal.ServerImplBuilder
- HappyThrottler() - Constructor for class io.grpc.rls.CachingRlsLbClient.HappyThrottler
- HARDCODED_CLASSES - Static variable in class io.grpc.LoadBalancerRegistry
- HAS_HEALTH_PRODUCER_LISTENER_KEY - Static variable in class io.grpc.LoadBalancer
- hasAdditional() - Method in class io.grpc.channelz.v1.SocketOption.Builder
-
Additional data associated with the socket option.
- hasAdditional() - Method in class io.grpc.channelz.v1.SocketOption
-
Additional data associated with the socket option.
- hasAdditional() - Method in interface io.grpc.channelz.v1.SocketOptionOrBuilder
-
Additional data associated with the socket option.
- hasAllExtensionNumbersOfType() - Method in class io.grpc.reflection.v1.ServerReflectionRequest.Builder
-
Finds the tag numbers used by all known extensions of the given message type, and appends them to ExtensionNumberResponse in an undefined order.
- hasAllExtensionNumbersOfType() - Method in class io.grpc.reflection.v1.ServerReflectionRequest
-
Finds the tag numbers used by all known extensions of the given message type, and appends them to ExtensionNumberResponse in an undefined order.
- hasAllExtensionNumbersOfType() - Method in interface io.grpc.reflection.v1.ServerReflectionRequestOrBuilder
-
Finds the tag numbers used by all known extensions of the given message type, and appends them to ExtensionNumberResponse in an undefined order.
- hasAllExtensionNumbersOfType() - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest.Builder
-
Finds the tag numbers used by all known extensions of extendee_type, and appends them to ExtensionNumberResponse in an undefined order.
- hasAllExtensionNumbersOfType() - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest
-
Finds the tag numbers used by all known extensions of extendee_type, and appends them to ExtensionNumberResponse in an undefined order.
- hasAllExtensionNumbersOfType() - Method in interface io.grpc.reflection.v1alpha.ServerReflectionRequestOrBuilder
-
Finds the tag numbers used by all known extensions of extendee_type, and appends them to ExtensionNumberResponse in an undefined order.
- hasAllExtensionNumbersResponse() - Method in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
-
This message is used to answer all_extension_numbers_of_type requests.
- hasAllExtensionNumbersResponse() - Method in class io.grpc.reflection.v1.ServerReflectionResponse
-
This message is used to answer all_extension_numbers_of_type requests.
- hasAllExtensionNumbersResponse() - Method in interface io.grpc.reflection.v1.ServerReflectionResponseOrBuilder
-
This message is used to answer all_extension_numbers_of_type requests.
- hasAllExtensionNumbersResponse() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
-
This message is used to answer all_extension_numbers_of_type requst.
- hasAllExtensionNumbersResponse() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse
-
This message is used to answer all_extension_numbers_of_type requst.
- hasAllExtensionNumbersResponse() - Method in interface io.grpc.reflection.v1alpha.ServerReflectionResponseOrBuilder
-
This message is used to answer all_extension_numbers_of_type requst.
- 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.
- hasArray() - Method in class io.grpc.internal.ReadableBuffers.ByteArrayWrapper
- hasArray() - Method in class io.grpc.internal.ReadableBuffers.ByteReadableBufferWrapper
- hasArray() - Method in class io.grpc.netty.NettyReadableBuffer
- HasByteBuffer - Interface in io.grpc
-
Extension to an
InputStream
whose content can be accessed asByteBuffer
s. - hasCacheEntry(K) - Method in class io.grpc.rls.LinkedHashLruCache
- hasCacheEntry(K) - Method in interface io.grpc.rls.LruCache
-
Returns
true
if given key is cached. - hasChannel() - Method in class io.grpc.channelz.v1.GetChannelResponse.Builder
-
The Channel that corresponds to the requested channel_id.
- hasChannel() - Method in class io.grpc.channelz.v1.GetChannelResponse
-
The Channel that corresponds to the requested channel_id.
- hasChannel() - Method in interface io.grpc.channelz.v1.GetChannelResponseOrBuilder
-
The Channel that corresponds to the requested channel_id.
- hasChannelRef() - Method in class io.grpc.channelz.v1.ChannelTraceEvent.Builder
-
.grpc.channelz.v1.ChannelRef channel_ref = 4;
- hasChannelRef() - Method in class io.grpc.channelz.v1.ChannelTraceEvent
-
.grpc.channelz.v1.ChannelRef channel_ref = 4;
- hasChannelRef() - Method in interface io.grpc.channelz.v1.ChannelTraceEventOrBuilder
-
.grpc.channelz.v1.ChannelRef channel_ref = 4;
- hasClientHeader() - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
.grpc.binarylog.v1.ClientHeader client_header = 6;
- hasClientHeader() - Method in class io.grpc.binarylog.v1.GrpcLogEntry
-
.grpc.binarylog.v1.ClientHeader client_header = 6;
- hasClientHeader() - Method in interface io.grpc.binarylog.v1.GrpcLogEntryOrBuilder
-
.grpc.binarylog.v1.ClientHeader client_header = 6;
- hasClientStats() - Method in class io.grpc.lb.v1.LoadBalanceRequest.Builder
-
The client stats should be periodically reported to the load balancer based on the duration defined in the InitialLoadBalanceResponse.
- hasClientStats() - Method in class io.grpc.lb.v1.LoadBalanceRequest
-
The client stats should be periodically reported to the load balancer based on the duration defined in the InitialLoadBalanceResponse.
- hasClientStats() - Method in interface io.grpc.lb.v1.LoadBalanceRequestOrBuilder
-
The client stats should be periodically reported to the load balancer based on the duration defined in the InitialLoadBalanceResponse.
- hasClientStatsReportInterval() - Method in class io.grpc.lb.v1.InitialLoadBalanceResponse.Builder
-
This interval defines how often the client should send the client stats to the load balancer.
- hasClientStatsReportInterval() - Method in class io.grpc.lb.v1.InitialLoadBalanceResponse
-
This interval defines how often the client should send the client stats to the load balancer.
- hasClientStatsReportInterval() - Method in interface io.grpc.lb.v1.InitialLoadBalanceResponseOrBuilder
-
This interval defines how often the client should send the client stats to the load balancer.
- hasCreationTimestamp() - Method in class io.grpc.channelz.v1.ChannelTrace.Builder
-
Time that this channel was created.
- hasCreationTimestamp() - Method in class io.grpc.channelz.v1.ChannelTrace
-
Time that this channel was created.
- hasCreationTimestamp() - Method in interface io.grpc.channelz.v1.ChannelTraceOrBuilder
-
Time that this channel was created.
- hasData() - Method in class io.grpc.channelz.v1.Channel.Builder
-
Data specific to this channel.
- hasData() - Method in class io.grpc.channelz.v1.Channel
-
Data specific to this channel.
- hasData() - Method in interface io.grpc.channelz.v1.ChannelOrBuilder
-
Data specific to this channel.
- hasData() - Method in class io.grpc.channelz.v1.Server.Builder
-
The associated data of the Server.
- hasData() - Method in class io.grpc.channelz.v1.Server
-
The associated data of the Server.
- hasData() - Method in interface io.grpc.channelz.v1.ServerOrBuilder
-
The associated data of the Server.
- hasData() - Method in class io.grpc.channelz.v1.Socket.Builder
-
Data specific to this Socket.
- hasData() - Method in class io.grpc.channelz.v1.Socket
-
Data specific to this Socket.
- hasData() - Method in interface io.grpc.channelz.v1.SocketOrBuilder
-
Data specific to this Socket.
- hasData() - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
Data specific to this channel.
- hasData() - Method in class io.grpc.channelz.v1.Subchannel
-
Data specific to this channel.
- hasData() - Method in interface io.grpc.channelz.v1.SubchannelOrBuilder
-
Data specific to this channel.
- hasData() - Method in class io.grpc.rls.CachingRlsLbClient.CachedRouteLookupResponse
- hasDeadline - Variable in class io.grpc.internal.ClientCallImpl.CancellationHandler
- hasDuration() - Method in class io.grpc.channelz.v1.SocketOptionLinger.Builder
-
duration maps to `struct linger.l_linger`
- hasDuration() - Method in class io.grpc.channelz.v1.SocketOptionLinger
-
duration maps to `struct linger.l_linger`
- hasDuration() - Method in interface io.grpc.channelz.v1.SocketOptionLingerOrBuilder
-
duration maps to `struct linger.l_linger`
- hasDuration() - Method in class io.grpc.channelz.v1.SocketOptionTimeout.Builder
-
.google.protobuf.Duration duration = 1;
- hasDuration() - Method in class io.grpc.channelz.v1.SocketOptionTimeout
-
.google.protobuf.Duration duration = 1;
- hasDuration() - Method in interface io.grpc.channelz.v1.SocketOptionTimeoutOrBuilder
-
.google.protobuf.Duration duration = 1;
- hasError() - Method in class io.grpc.rls.CachingRlsLbClient.CachedRouteLookupResponse
- hasErrorResponse() - Method in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
-
This message is used when an error occurs.
- hasErrorResponse() - Method in class io.grpc.reflection.v1.ServerReflectionResponse
-
This message is used when an error occurs.
- hasErrorResponse() - Method in interface io.grpc.reflection.v1.ServerReflectionResponseOrBuilder
-
This message is used when an error occurs.
- hasErrorResponse() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
-
This message is used when an error occurs.
- hasErrorResponse() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse
-
This message is used when an error occurs.
- hasErrorResponse() - Method in interface io.grpc.reflection.v1alpha.ServerReflectionResponseOrBuilder
-
This message is used when an error occurs.
- hasExtraKeys() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
-
.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys extra_keys = 3;
- hasExtraKeys() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder
-
.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys extra_keys = 3;
- hasExtraKeys() - Method in interface io.grpc.lookup.v1.GrpcKeyBuilderOrBuilder
-
.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys extra_keys = 3;
- hasFallbackResponse() - Method in class io.grpc.lb.v1.LoadBalanceResponse.Builder
-
If this field is set, then the client should eagerly enter fallback mode (even if there are existing, healthy connections to backends).
- hasFallbackResponse() - Method in class io.grpc.lb.v1.LoadBalanceResponse
-
If this field is set, then the client should eagerly enter fallback mode (even if there are existing, healthy connections to backends).
- hasFallbackResponse() - Method in interface io.grpc.lb.v1.LoadBalanceResponseOrBuilder
-
If this field is set, then the client should eagerly enter fallback mode (even if there are existing, healthy connections to backends).
- hasFileByFilename() - Method in class io.grpc.reflection.v1.ServerReflectionRequest.Builder
-
Find a proto file by the file name.
- hasFileByFilename() - Method in class io.grpc.reflection.v1.ServerReflectionRequest
-
Find a proto file by the file name.
- hasFileByFilename() - Method in interface io.grpc.reflection.v1.ServerReflectionRequestOrBuilder
-
Find a proto file by the file name.
- hasFileByFilename() - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest.Builder
-
Find a proto file by the file name.
- hasFileByFilename() - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest
-
Find a proto file by the file name.
- hasFileByFilename() - Method in interface io.grpc.reflection.v1alpha.ServerReflectionRequestOrBuilder
-
Find a proto file by the file name.
- hasFileContainingExtension() - Method in class io.grpc.reflection.v1.ServerReflectionRequest.Builder
-
Find the proto file which defines an extension extending the given message type with the given field number.
- hasFileContainingExtension() - Method in class io.grpc.reflection.v1.ServerReflectionRequest
-
Find the proto file which defines an extension extending the given message type with the given field number.
- hasFileContainingExtension() - Method in interface io.grpc.reflection.v1.ServerReflectionRequestOrBuilder
-
Find the proto file which defines an extension extending the given message type with the given field number.
- hasFileContainingExtension() - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest.Builder
-
Find the proto file which defines an extension extending the given message type with the given field number.
- hasFileContainingExtension() - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest
-
Find the proto file which defines an extension extending the given message type with the given field number.
- hasFileContainingExtension() - Method in interface io.grpc.reflection.v1alpha.ServerReflectionRequestOrBuilder
-
Find the proto file which defines an extension extending the given message type with the given field number.
- hasFileContainingSymbol() - Method in class io.grpc.reflection.v1.ServerReflectionRequest.Builder
-
Find the proto file that declares the given fully-qualified symbol name.
- hasFileContainingSymbol() - Method in class io.grpc.reflection.v1.ServerReflectionRequest
-
Find the proto file that declares the given fully-qualified symbol name.
- hasFileContainingSymbol() - Method in interface io.grpc.reflection.v1.ServerReflectionRequestOrBuilder
-
Find the proto file that declares the given fully-qualified symbol name.
- hasFileContainingSymbol() - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest.Builder
-
Find the proto file that declares the given fully-qualified symbol name.
- hasFileContainingSymbol() - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest
-
Find the proto file that declares the given fully-qualified symbol name.
- hasFileContainingSymbol() - Method in interface io.grpc.reflection.v1alpha.ServerReflectionRequestOrBuilder
-
Find the proto file that declares the given fully-qualified symbol name.
- hasFileDescriptorResponse() - Method in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
-
This message is used to answer file_by_filename, file_containing_symbol, file_containing_extension requests with transitive dependencies.
- hasFileDescriptorResponse() - Method in class io.grpc.reflection.v1.ServerReflectionResponse
-
This message is used to answer file_by_filename, file_containing_symbol, file_containing_extension requests with transitive dependencies.
- hasFileDescriptorResponse() - Method in interface io.grpc.reflection.v1.ServerReflectionResponseOrBuilder
-
This message is used to answer file_by_filename, file_containing_symbol, file_containing_extension requests with transitive dependencies.
- hasFileDescriptorResponse() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
-
This message is used to answer file_by_filename, file_containing_symbol, file_containing_extension requests with transitive dependencies.
- hasFileDescriptorResponse() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse
-
This message is used to answer file_by_filename, file_containing_symbol, file_containing_extension requests with transitive dependencies.
- hasFileDescriptorResponse() - Method in interface io.grpc.reflection.v1alpha.ServerReflectionResponseOrBuilder
-
This message is used to answer file_by_filename, file_containing_symbol, file_containing_extension requests with transitive dependencies.
- hashCode - Variable in class io.grpc.EquivalentAddressGroup
-
SocketAddress
docs say that the addresses are immutable, so we cache the hashCode. - hashCode - Variable in class io.grpc.util.MultiChildLoadBalancer.Endpoint
- hashCode - Variable in class io.grpc.util.RoundRobinLoadBalancer.ReadyPicker
- hashCode() - Method in class io.grpc.Attributes
-
Returns a hash code for the attributes.
- hashCode() - Method in class io.grpc.binarylog.v1.Address
- hashCode() - Method in class io.grpc.binarylog.v1.ClientHeader
- hashCode() - Method in class io.grpc.binarylog.v1.GrpcLogEntry
- hashCode() - Method in class io.grpc.binarylog.v1.Message
- hashCode() - Method in class io.grpc.binarylog.v1.Metadata
- hashCode() - Method in class io.grpc.binarylog.v1.MetadataEntry
- hashCode() - Method in class io.grpc.binarylog.v1.ServerHeader
- hashCode() - Method in class io.grpc.binarylog.v1.Trailer
- hashCode() - Method in class io.grpc.channelz.v1.Address
- hashCode() - Method in class io.grpc.channelz.v1.Address.OtherAddress
- hashCode() - Method in class io.grpc.channelz.v1.Address.TcpIpAddress
- hashCode() - Method in class io.grpc.channelz.v1.Address.UdsAddress
- hashCode() - Method in class io.grpc.channelz.v1.Channel
- hashCode() - Method in class io.grpc.channelz.v1.ChannelConnectivityState
- hashCode() - Method in class io.grpc.channelz.v1.ChannelData
- hashCode() - Method in class io.grpc.channelz.v1.ChannelRef
- hashCode() - Method in class io.grpc.channelz.v1.ChannelTrace
- hashCode() - Method in class io.grpc.channelz.v1.ChannelTraceEvent
- hashCode() - Method in class io.grpc.channelz.v1.GetChannelRequest
- hashCode() - Method in class io.grpc.channelz.v1.GetChannelResponse
- hashCode() - Method in class io.grpc.channelz.v1.GetServerRequest
- hashCode() - Method in class io.grpc.channelz.v1.GetServerResponse
- hashCode() - Method in class io.grpc.channelz.v1.GetServerSocketsRequest
- hashCode() - Method in class io.grpc.channelz.v1.GetServerSocketsResponse
- hashCode() - Method in class io.grpc.channelz.v1.GetServersRequest
- hashCode() - Method in class io.grpc.channelz.v1.GetServersResponse
- hashCode() - Method in class io.grpc.channelz.v1.GetSocketRequest
- hashCode() - Method in class io.grpc.channelz.v1.GetSocketResponse
- hashCode() - Method in class io.grpc.channelz.v1.GetSubchannelRequest
- hashCode() - Method in class io.grpc.channelz.v1.GetSubchannelResponse
- hashCode() - Method in class io.grpc.channelz.v1.GetTopChannelsRequest
- hashCode() - Method in class io.grpc.channelz.v1.GetTopChannelsResponse
- hashCode() - Method in class io.grpc.channelz.v1.Security
- hashCode() - Method in class io.grpc.channelz.v1.Security.OtherSecurity
- hashCode() - Method in class io.grpc.channelz.v1.Security.Tls
- hashCode() - Method in class io.grpc.channelz.v1.Server
- hashCode() - Method in class io.grpc.channelz.v1.ServerData
- hashCode() - Method in class io.grpc.channelz.v1.ServerRef
- hashCode() - Method in class io.grpc.channelz.v1.Socket
- hashCode() - Method in class io.grpc.channelz.v1.SocketData
- hashCode() - Method in class io.grpc.channelz.v1.SocketOption
- hashCode() - Method in class io.grpc.channelz.v1.SocketOptionLinger
- hashCode() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo
- hashCode() - Method in class io.grpc.channelz.v1.SocketOptionTimeout
- hashCode() - Method in class io.grpc.channelz.v1.SocketRef
- hashCode() - Method in class io.grpc.channelz.v1.Subchannel
- hashCode() - Method in class io.grpc.channelz.v1.SubchannelRef
- hashCode() - Method in class io.grpc.ConnectivityStateInfo
- hashCode() - Method in class io.grpc.Deadline
- hashCode() - Method in class io.grpc.EquivalentAddressGroup
- hashCode() - Method in class io.grpc.grpclb.GrpclbConfig
- hashCode() - Method in class io.grpc.grpclb.GrpclbState.BackendEntry
- hashCode() - Method in class io.grpc.grpclb.GrpclbState.DropEntry
- hashCode() - Method in class io.grpc.grpclb.GrpclbState.ErrorEntry
- hashCode() - Method in class io.grpc.grpclb.GrpclbState.IdleSubchannelEntry
- hashCode() - Method in class io.grpc.grpclb.TokenAttachingTracerFactory
- hashCode() - Method in class io.grpc.health.v1.HealthCheckRequest
- hashCode() - Method in class io.grpc.health.v1.HealthCheckResponse
- hashCode() - Method in class io.grpc.HttpConnectProxiedSocketAddress
- hashCode() - Method in class io.grpc.inprocess.InProcessSocketAddress
- hashCode() - Method in class io.grpc.internal.ClientTransportFactory.ClientTransportOptions
- hashCode() - Method in class io.grpc.internal.DnsNameResolver.SrvRecord
- hashCode() - Method in class io.grpc.internal.HedgingPolicy
- hashCode() - Method in class io.grpc.internal.ManagedChannelServiceConfig
- hashCode() - Method in class io.grpc.internal.ManagedChannelServiceConfig.MethodInfo
- hashCode() - Method in class io.grpc.internal.PickSubchannelArgsImpl
- hashCode() - Method in class io.grpc.internal.RetriableStream.Throttle
- hashCode() - Method in class io.grpc.internal.RetryPolicy
- hashCode() - Method in class io.grpc.internal.ServerCallInfoImpl
- hashCode() - Method in class io.grpc.internal.ServiceConfigUtil.LbConfig
- hashCode() - Method in class io.grpc.internal.ServiceConfigUtil.PolicySelection
- hashCode() - Method in class io.grpc.InternalChannelz.ChannelTrace.Event
- hashCode() - Method in class io.grpc.lb.v1.ClientStats
- hashCode() - Method in class io.grpc.lb.v1.ClientStatsPerToken
- hashCode() - Method in class io.grpc.lb.v1.FallbackResponse
- hashCode() - Method in class io.grpc.lb.v1.InitialLoadBalanceRequest
- hashCode() - Method in class io.grpc.lb.v1.InitialLoadBalanceResponse
- hashCode() - Method in class io.grpc.lb.v1.LoadBalanceRequest
- hashCode() - Method in class io.grpc.lb.v1.LoadBalanceResponse
- hashCode() - Method in class io.grpc.lb.v1.Server
- hashCode() - Method in class io.grpc.lb.v1.ServerList
- hashCode() - Method in class io.grpc.LoadBalancer.FixedResultPicker
- hashCode() - Method in class io.grpc.LoadBalancer.PickResult
- hashCode() - Method in class io.grpc.LoadBalancer.ResolvedAddresses
- hashCode() - Method in class io.grpc.LoadBalancerProvider
- hashCode() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys
- hashCode() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder
- hashCode() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Name
- hashCode() - Method in class io.grpc.lookup.v1.HttpKeyBuilder
- hashCode() - Method in class io.grpc.lookup.v1.NameMatcher
- hashCode() - Method in class io.grpc.lookup.v1.RouteLookupClusterSpecifier
- hashCode() - Method in class io.grpc.lookup.v1.RouteLookupConfig
- hashCode() - Method in class io.grpc.lookup.v1.RouteLookupRequest
- hashCode() - Method in class io.grpc.lookup.v1.RouteLookupResponse
- hashCode() - Method in class io.grpc.Metadata.Key
- hashCode() - Method in class io.grpc.NameResolver.ConfigOrError
- hashCode() - Method in class io.grpc.NameResolver.ResolutionResult
-
Useful for testing.
- hashCode() - Method in class io.grpc.netty.CancelServerStreamCommand
- hashCode() - Method in class io.grpc.netty.ProtocolNegotiationEvent
-
This method is not efficient and is intended for testing.
- hashCode() - Method in class io.grpc.netty.SendGrpcFrameCommand
- hashCode() - Method in class io.grpc.netty.SendResponseHeadersCommand
- hashCode() - Method in class io.grpc.reflection.v1.ErrorResponse
- hashCode() - Method in class io.grpc.reflection.v1.ExtensionNumberResponse
- hashCode() - Method in class io.grpc.reflection.v1.ExtensionRequest
- hashCode() - Method in class io.grpc.reflection.v1.FileDescriptorResponse
- hashCode() - Method in class io.grpc.reflection.v1.ListServiceResponse
- hashCode() - Method in class io.grpc.reflection.v1.ServerReflectionRequest
- hashCode() - Method in class io.grpc.reflection.v1.ServerReflectionResponse
- hashCode() - Method in class io.grpc.reflection.v1.ServiceResponse
- hashCode() - Method in class io.grpc.reflection.v1alpha.ErrorResponse
- hashCode() - Method in class io.grpc.reflection.v1alpha.ExtensionNumberResponse
- hashCode() - Method in class io.grpc.reflection.v1alpha.ExtensionRequest
- hashCode() - Method in class io.grpc.reflection.v1alpha.FileDescriptorResponse
- hashCode() - Method in class io.grpc.reflection.v1alpha.ListServiceResponse
- hashCode() - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest
- hashCode() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse
- hashCode() - Method in class io.grpc.reflection.v1alpha.ServiceResponse
- hashCode() - Method in class io.grpc.rls.AutoValue_RlsProtoData_ExtraKeys
- hashCode() - Method in class io.grpc.rls.AutoValue_RlsProtoData_GrpcKeyBuilder_Name
- hashCode() - Method in class io.grpc.rls.AutoValue_RlsProtoData_GrpcKeyBuilder
- hashCode() - Method in class io.grpc.rls.AutoValue_RlsProtoData_NameMatcher
- hashCode() - Method in class io.grpc.rls.AutoValue_RlsProtoData_RouteLookupConfig
- hashCode() - Method in class io.grpc.rls.AutoValue_RlsProtoData_RouteLookupRequest
- hashCode() - Method in class io.grpc.rls.AutoValue_RlsProtoData_RouteLookupResponse
- hashCode() - Method in class io.grpc.rls.LbPolicyConfiguration.ChildLoadBalancingPolicy
- hashCode() - Method in class io.grpc.rls.LbPolicyConfiguration
- hashCode() - Method in class io.grpc.rls.LinkedHashLruCache.SizedValue
- hashCode() - Method in class io.grpc.Status
-
Hash codes on Statuses are not well defined.
- hashCode() - Method in class io.grpc.StatusOr
- hashCode() - Method in class io.grpc.util.GracefulSwitchLoadBalancer.Config
- hashCode() - Method in class io.grpc.util.MultiChildLoadBalancer.Endpoint
- hashCode() - Method in class io.grpc.util.RoundRobinLoadBalancer.ReadyPicker
- hasInitialRequest() - Method in class io.grpc.lb.v1.LoadBalanceRequest.Builder
-
This message should be sent on the first request to the load balancer.
- hasInitialRequest() - Method in class io.grpc.lb.v1.LoadBalanceRequest
-
This message should be sent on the first request to the load balancer.
- hasInitialRequest() - Method in interface io.grpc.lb.v1.LoadBalanceRequestOrBuilder
-
This message should be sent on the first request to the load balancer.
- hasInitialResponse() - Method in class io.grpc.lb.v1.LoadBalanceResponse.Builder
-
This message should be sent on the first response to the client.
- hasInitialResponse() - Method in class io.grpc.lb.v1.LoadBalanceResponse
-
This message should be sent on the first response to the client.
- hasInitialResponse() - Method in interface io.grpc.lb.v1.LoadBalanceResponseOrBuilder
-
This message should be sent on the first response to the client.
- hasLastCallStartedTimestamp() - Method in class io.grpc.channelz.v1.ChannelData.Builder
-
The last time a call was started on the channel.
- hasLastCallStartedTimestamp() - Method in class io.grpc.channelz.v1.ChannelData
-
The last time a call was started on the channel.
- hasLastCallStartedTimestamp() - Method in interface io.grpc.channelz.v1.ChannelDataOrBuilder
-
The last time a call was started on the channel.
- hasLastCallStartedTimestamp() - Method in class io.grpc.channelz.v1.ServerData.Builder
-
The last time a call was started on the server.
- hasLastCallStartedTimestamp() - Method in class io.grpc.channelz.v1.ServerData
-
The last time a call was started on the server.
- hasLastCallStartedTimestamp() - Method in interface io.grpc.channelz.v1.ServerDataOrBuilder
-
The last time a call was started on the server.
- hasLastLocalStreamCreatedTimestamp() - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The last time a stream was created by this endpoint.
- hasLastLocalStreamCreatedTimestamp() - Method in class io.grpc.channelz.v1.SocketData
-
The last time a stream was created by this endpoint.
- hasLastLocalStreamCreatedTimestamp() - Method in interface io.grpc.channelz.v1.SocketDataOrBuilder
-
The last time a stream was created by this endpoint.
- hasLastMessageReceivedTimestamp() - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The last time a message was received by this endpoint.
- hasLastMessageReceivedTimestamp() - Method in class io.grpc.channelz.v1.SocketData
-
The last time a message was received by this endpoint.
- hasLastMessageReceivedTimestamp() - Method in interface io.grpc.channelz.v1.SocketDataOrBuilder
-
The last time a message was received by this endpoint.
- hasLastMessageSentTimestamp() - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The last time a message was sent by this endpoint.
- hasLastMessageSentTimestamp() - Method in class io.grpc.channelz.v1.SocketData
-
The last time a message was sent by this endpoint.
- hasLastMessageSentTimestamp() - Method in interface io.grpc.channelz.v1.SocketDataOrBuilder
-
The last time a message was sent by this endpoint.
- hasLastRemoteStreamCreatedTimestamp() - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The last time a stream was created by the remote endpoint.
- hasLastRemoteStreamCreatedTimestamp() - Method in class io.grpc.channelz.v1.SocketData
-
The last time a stream was created by the remote endpoint.
- hasLastRemoteStreamCreatedTimestamp() - Method in interface io.grpc.channelz.v1.SocketDataOrBuilder
-
The last time a stream was created by the remote endpoint.
- hasListServices() - Method in class io.grpc.reflection.v1.ServerReflectionRequest.Builder
-
List the full names of registered services.
- hasListServices() - Method in class io.grpc.reflection.v1.ServerReflectionRequest
-
List the full names of registered services.
- hasListServices() - Method in interface io.grpc.reflection.v1.ServerReflectionRequestOrBuilder
-
List the full names of registered services.
- hasListServices() - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest.Builder
-
List the full names of registered services.
- hasListServices() - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest
-
List the full names of registered services.
- hasListServices() - Method in interface io.grpc.reflection.v1alpha.ServerReflectionRequestOrBuilder
-
List the full names of registered services.
- hasListServicesResponse() - Method in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
-
This message is used to answer list_services requests.
- hasListServicesResponse() - Method in class io.grpc.reflection.v1.ServerReflectionResponse
-
This message is used to answer list_services requests.
- hasListServicesResponse() - Method in interface io.grpc.reflection.v1.ServerReflectionResponseOrBuilder
-
This message is used to answer list_services requests.
- hasListServicesResponse() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
-
This message is used to answer list_services request.
- hasListServicesResponse() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse
-
This message is used to answer list_services request.
- hasListServicesResponse() - Method in interface io.grpc.reflection.v1alpha.ServerReflectionResponseOrBuilder
-
This message is used to answer list_services request.
- hasLocal() - Method in class io.grpc.channelz.v1.Socket.Builder
-
The locally bound address.
- hasLocal() - Method in class io.grpc.channelz.v1.Socket
-
The locally bound address.
- hasLocal() - Method in interface io.grpc.channelz.v1.SocketOrBuilder
-
The locally bound address.
- hasLocalFlowControlWindow() - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The amount of window, granted to the local endpoint by the remote endpoint.
- hasLocalFlowControlWindow() - Method in class io.grpc.channelz.v1.SocketData
-
The amount of window, granted to the local endpoint by the remote endpoint.
- hasLocalFlowControlWindow() - Method in interface io.grpc.channelz.v1.SocketDataOrBuilder
-
The amount of window, granted to the local endpoint by the remote endpoint.
- hasLookupServiceTimeout() - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
Configure a timeout value for lookup service requests.
- hasLookupServiceTimeout() - Method in class io.grpc.lookup.v1.RouteLookupConfig
-
Configure a timeout value for lookup service requests.
- hasLookupServiceTimeout() - Method in interface io.grpc.lookup.v1.RouteLookupConfigOrBuilder
-
Configure a timeout value for lookup service requests.
- hasMaxAge() - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
How long are responses valid for (like HTTP Cache-Control).
- hasMaxAge() - Method in class io.grpc.lookup.v1.RouteLookupConfig
-
How long are responses valid for (like HTTP Cache-Control).
- hasMaxAge() - Method in interface io.grpc.lookup.v1.RouteLookupConfigOrBuilder
-
How long are responses valid for (like HTTP Cache-Control).
- hasMessage() - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
Used by EVENT_TYPE_CLIENT_MESSAGE, EVENT_TYPE_SERVER_MESSAGE
- hasMessage() - Method in class io.grpc.binarylog.v1.GrpcLogEntry
-
Used by EVENT_TYPE_CLIENT_MESSAGE, EVENT_TYPE_SERVER_MESSAGE
- hasMessage() - Method in interface io.grpc.binarylog.v1.GrpcLogEntryOrBuilder
-
Used by EVENT_TYPE_CLIENT_MESSAGE, EVENT_TYPE_SERVER_MESSAGE
- hasMetadata() - Method in class io.grpc.binarylog.v1.ClientHeader.Builder
-
This contains only the metadata from the application.
- hasMetadata() - Method in class io.grpc.binarylog.v1.ClientHeader
-
This contains only the metadata from the application.
- hasMetadata() - Method in interface io.grpc.binarylog.v1.ClientHeaderOrBuilder
-
This contains only the metadata from the application.
- hasMetadata() - Method in class io.grpc.binarylog.v1.ServerHeader.Builder
-
This contains only the metadata from the application.
- hasMetadata() - Method in class io.grpc.binarylog.v1.ServerHeader
-
This contains only the metadata from the application.
- hasMetadata() - Method in interface io.grpc.binarylog.v1.ServerHeaderOrBuilder
-
This contains only the metadata from the application.
- hasMetadata() - Method in class io.grpc.binarylog.v1.Trailer.Builder
-
This contains only the metadata from the application.
- hasMetadata() - Method in class io.grpc.binarylog.v1.Trailer
-
This contains only the metadata from the application.
- hasMetadata() - Method in interface io.grpc.binarylog.v1.TrailerOrBuilder
-
This contains only the metadata from the application.
- hasNext() - Method in class io.grpc.netty.GrpcHttp2OutboundHeaders.Itr
- hasNext() - Method in class io.grpc.stub.ClientCalls.BlockingResponseStream
- hasOriginalRequest() - Method in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
-
.grpc.reflection.v1.ServerReflectionRequest original_request = 2;
- hasOriginalRequest() - Method in class io.grpc.reflection.v1.ServerReflectionResponse
-
.grpc.reflection.v1.ServerReflectionRequest original_request = 2;
- hasOriginalRequest() - Method in interface io.grpc.reflection.v1.ServerReflectionResponseOrBuilder
-
.grpc.reflection.v1.ServerReflectionRequest original_request = 2;
- hasOriginalRequest() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
-
.grpc.reflection.v1alpha.ServerReflectionRequest original_request = 2;
- hasOriginalRequest() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse
-
.grpc.reflection.v1alpha.ServerReflectionRequest original_request = 2;
- hasOriginalRequest() - Method in interface io.grpc.reflection.v1alpha.ServerReflectionResponseOrBuilder
-
.grpc.reflection.v1alpha.ServerReflectionRequest original_request = 2;
- hasOther() - Method in class io.grpc.channelz.v1.Security.Builder
-
.grpc.channelz.v1.Security.OtherSecurity other = 2;
- hasOther() - Method in class io.grpc.channelz.v1.Security
-
.grpc.channelz.v1.Security.OtherSecurity other = 2;
- hasOther() - Method in interface io.grpc.channelz.v1.SecurityOrBuilder
-
.grpc.channelz.v1.Security.OtherSecurity other = 2;
- hasOtherAddress() - Method in class io.grpc.channelz.v1.Address.Builder
-
.grpc.channelz.v1.Address.OtherAddress other_address = 3;
- hasOtherAddress() - Method in class io.grpc.channelz.v1.Address
-
.grpc.channelz.v1.Address.OtherAddress other_address = 3;
- hasOtherAddress() - Method in interface io.grpc.channelz.v1.AddressOrBuilder
-
.grpc.channelz.v1.Address.OtherAddress other_address = 3;
- hasOtherName() - Method in class io.grpc.channelz.v1.Security.Tls.Builder
-
Some other way to describe the cipher suite if the RFC 4346 name is not available.
- hasOtherName() - Method in class io.grpc.channelz.v1.Security.Tls
-
Some other way to describe the cipher suite if the RFC 4346 name is not available.
- hasOtherName() - Method in interface io.grpc.channelz.v1.Security.TlsOrBuilder
-
Some other way to describe the cipher suite if the RFC 4346 name is not available.
- hasOutstandingCalls - Variable in class io.grpc.internal.KeepAliveEnforcer
- hasPartialData() - Method in class io.grpc.internal.GzipInflatingBuffer
-
Returns true when there is gzippedData that has not been input to the inflater or the inflater has not consumed all of its input, or all data has been consumed but we are at not at the boundary between gzip streams.
- hasPeer() - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
Peer address information, will only be recorded on the first incoming event.
- hasPeer() - Method in class io.grpc.binarylog.v1.GrpcLogEntry
-
Peer address information, will only be recorded on the first incoming event.
- hasPeer() - Method in interface io.grpc.binarylog.v1.GrpcLogEntryOrBuilder
-
Peer address information, will only be recorded on the first incoming event.
- hasPendingDeliveries() - Method in class io.grpc.internal.MessageDeframer
- hasPendingStreams() - Method in class io.grpc.internal.DelayedClientTransport
- hasPotentialHedging(RetriableStream.State) - Method in class io.grpc.internal.RetriableStream
-
Whether there is any potential hedge at the moment.
- hasRef() - Method in class io.grpc.channelz.v1.Channel.Builder
-
The identifier for this channel.
- hasRef() - Method in class io.grpc.channelz.v1.Channel
-
The identifier for this channel.
- hasRef() - Method in interface io.grpc.channelz.v1.ChannelOrBuilder
-
The identifier for this channel.
- hasRef() - Method in class io.grpc.channelz.v1.Server.Builder
-
The identifier for a Server.
- hasRef() - Method in class io.grpc.channelz.v1.Server
-
The identifier for a Server.
- hasRef() - Method in interface io.grpc.channelz.v1.ServerOrBuilder
-
The identifier for a Server.
- hasRef() - Method in class io.grpc.channelz.v1.Socket.Builder
-
The identifier for the Socket.
- hasRef() - Method in class io.grpc.channelz.v1.Socket
-
The identifier for the Socket.
- hasRef() - Method in interface io.grpc.channelz.v1.SocketOrBuilder
-
The identifier for the Socket.
- hasRef() - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
The identifier for this channel.
- hasRef() - Method in class io.grpc.channelz.v1.Subchannel
-
The identifier for this channel.
- hasRef() - Method in interface io.grpc.channelz.v1.SubchannelOrBuilder
-
The identifier for this channel.
- hasRemote() - Method in class io.grpc.channelz.v1.Socket.Builder
-
The remote bound address.
- hasRemote() - Method in class io.grpc.channelz.v1.Socket
-
The remote bound address.
- hasRemote() - Method in interface io.grpc.channelz.v1.SocketOrBuilder
-
The remote bound address.
- hasRemoteFlowControlWindow() - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The amount of window, granted to the remote endpoint by the local endpoint.
- hasRemoteFlowControlWindow() - Method in class io.grpc.channelz.v1.SocketData
-
The amount of window, granted to the remote endpoint by the local endpoint.
- hasRemoteFlowControlWindow() - Method in interface io.grpc.channelz.v1.SocketDataOrBuilder
-
The amount of window, granted to the remote endpoint by the local endpoint.
- hasResult() - Method in class io.grpc.LoadBalancer.PickResult
-
Returns
true
if the pick was not created withLoadBalancer.PickResult.withNoResult()
. - hasRouteLookupConfig() - Method in class io.grpc.lookup.v1.RouteLookupClusterSpecifier.Builder
-
The RLS config for this cluster specifier plugin instance.
- hasRouteLookupConfig() - Method in class io.grpc.lookup.v1.RouteLookupClusterSpecifier
-
The RLS config for this cluster specifier plugin instance.
- hasRouteLookupConfig() - Method in interface io.grpc.lookup.v1.RouteLookupClusterSpecifierOrBuilder
-
The RLS config for this cluster specifier plugin instance.
- hasSecurity() - Method in class io.grpc.channelz.v1.Socket.Builder
-
Security details for this socket.
- hasSecurity() - Method in class io.grpc.channelz.v1.Socket
-
Security details for this socket.
- hasSecurity() - Method in interface io.grpc.channelz.v1.SocketOrBuilder
-
Security details for this socket.
- hasServer() - Method in class io.grpc.channelz.v1.GetServerResponse.Builder
-
The Server that corresponds to the requested server_id.
- hasServer() - Method in class io.grpc.channelz.v1.GetServerResponse
-
The Server that corresponds to the requested server_id.
- hasServer() - Method in interface io.grpc.channelz.v1.GetServerResponseOrBuilder
-
The Server that corresponds to the requested server_id.
- hasServerHeader() - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
.grpc.binarylog.v1.ServerHeader server_header = 7;
- hasServerHeader() - Method in class io.grpc.binarylog.v1.GrpcLogEntry
-
.grpc.binarylog.v1.ServerHeader server_header = 7;
- hasServerHeader() - Method in interface io.grpc.binarylog.v1.GrpcLogEntryOrBuilder
-
.grpc.binarylog.v1.ServerHeader server_header = 7;
- hasServerList() - Method in class io.grpc.lb.v1.LoadBalanceResponse.Builder
-
Contains the list of servers selected by the load balancer.
- hasServerList() - Method in class io.grpc.lb.v1.LoadBalanceResponse
-
Contains the list of servers selected by the load balancer.
- hasServerList() - Method in interface io.grpc.lb.v1.LoadBalanceResponseOrBuilder
-
Contains the list of servers selected by the load balancer.
- hasSingleAddress(List<EquivalentAddressGroup>) - Static method in class io.grpc.util.OutlierDetectionLoadBalancer
-
Counts how many addresses are in a given address group.
- hasSocket() - Method in class io.grpc.channelz.v1.GetSocketResponse.Builder
-
The Socket that corresponds to the requested socket_id.
- hasSocket() - Method in class io.grpc.channelz.v1.GetSocketResponse
-
The Socket that corresponds to the requested socket_id.
- hasSocket() - Method in interface io.grpc.channelz.v1.GetSocketResponseOrBuilder
-
The Socket that corresponds to the requested socket_id.
- hasStaleAge() - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
After a response has been in the client cache for this amount of time and is re-requested, start an asynchronous RPC to re-validate it.
- hasStaleAge() - Method in class io.grpc.lookup.v1.RouteLookupConfig
-
After a response has been in the client cache for this amount of time and is re-requested, start an asynchronous RPC to re-validate it.
- hasStaleAge() - Method in interface io.grpc.lookup.v1.RouteLookupConfigOrBuilder
-
After a response has been in the client cache for this amount of time and is re-requested, start an asynchronous RPC to re-validate it.
- hasStandardName() - Method in class io.grpc.channelz.v1.Security.Tls.Builder
-
The cipher suite name in the RFC 4346 format: https://tools.ietf.org/html/rfc4346#appendix-C
- hasStandardName() - Method in class io.grpc.channelz.v1.Security.Tls
-
The cipher suite name in the RFC 4346 format: https://tools.ietf.org/html/rfc4346#appendix-C
- hasStandardName() - Method in interface io.grpc.channelz.v1.Security.TlsOrBuilder
-
The cipher suite name in the RFC 4346 format: https://tools.ietf.org/html/rfc4346#appendix-C
- hasStarted - Variable in class io.grpc.SynchronizationContext.ManagedRunnable
- hasState() - Method in class io.grpc.channelz.v1.ChannelData.Builder
-
The connectivity state of the channel or subchannel.
- hasState() - Method in class io.grpc.channelz.v1.ChannelData
-
The connectivity state of the channel or subchannel.
- hasState() - Method in interface io.grpc.channelz.v1.ChannelDataOrBuilder
-
The connectivity state of the channel or subchannel.
- hasSubchannel() - Method in class io.grpc.channelz.v1.GetSubchannelResponse.Builder
-
The Subchannel that corresponds to the requested subchannel_id.
- hasSubchannel() - Method in class io.grpc.channelz.v1.GetSubchannelResponse
-
The Subchannel that corresponds to the requested subchannel_id.
- hasSubchannel() - Method in interface io.grpc.channelz.v1.GetSubchannelResponseOrBuilder
-
The Subchannel that corresponds to the requested subchannel_id.
- hasSubchannelRef() - Method in class io.grpc.channelz.v1.ChannelTraceEvent.Builder
-
.grpc.channelz.v1.SubchannelRef subchannel_ref = 5;
- hasSubchannelRef() - Method in class io.grpc.channelz.v1.ChannelTraceEvent
-
.grpc.channelz.v1.SubchannelRef subchannel_ref = 5;
- hasSubchannelRef() - Method in interface io.grpc.channelz.v1.ChannelTraceEventOrBuilder
-
.grpc.channelz.v1.SubchannelRef subchannel_ref = 5;
- hasTcpipAddress() - Method in class io.grpc.channelz.v1.Address.Builder
-
.grpc.channelz.v1.Address.TcpIpAddress tcpip_address = 1;
- hasTcpipAddress() - Method in class io.grpc.channelz.v1.Address
-
.grpc.channelz.v1.Address.TcpIpAddress tcpip_address = 1;
- hasTcpipAddress() - Method in interface io.grpc.channelz.v1.AddressOrBuilder
-
.grpc.channelz.v1.Address.TcpIpAddress tcpip_address = 1;
- hasThrottle() - Method in class io.grpc.internal.ManagedChannelImpl
- hasTimeout() - Method in class io.grpc.binarylog.v1.ClientHeader.Builder
-
the RPC timeout
- hasTimeout() - Method in class io.grpc.binarylog.v1.ClientHeader
-
the RPC timeout
- hasTimeout() - Method in interface io.grpc.binarylog.v1.ClientHeaderOrBuilder
-
the RPC timeout
- hasTimestamp() - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
The timestamp of the binary log message
- hasTimestamp() - Method in class io.grpc.binarylog.v1.GrpcLogEntry
-
The timestamp of the binary log message
- hasTimestamp() - Method in interface io.grpc.binarylog.v1.GrpcLogEntryOrBuilder
-
The timestamp of the binary log message
- hasTimestamp() - Method in class io.grpc.channelz.v1.ChannelTraceEvent.Builder
-
When this event occurred.
- hasTimestamp() - Method in class io.grpc.channelz.v1.ChannelTraceEvent
-
When this event occurred.
- hasTimestamp() - Method in interface io.grpc.channelz.v1.ChannelTraceEventOrBuilder
-
When this event occurred.
- hasTimestamp() - Method in class io.grpc.lb.v1.ClientStats.Builder
-
The timestamp of generating the report.
- hasTimestamp() - Method in class io.grpc.lb.v1.ClientStats
-
The timestamp of generating the report.
- hasTimestamp() - Method in interface io.grpc.lb.v1.ClientStatsOrBuilder
-
The timestamp of generating the report.
- hasTls() - Method in class io.grpc.channelz.v1.Security.Builder
-
.grpc.channelz.v1.Security.Tls tls = 1;
- hasTls() - Method in class io.grpc.channelz.v1.Security
-
.grpc.channelz.v1.Security.Tls tls = 1;
- hasTls() - Method in interface io.grpc.channelz.v1.SecurityOrBuilder
-
.grpc.channelz.v1.Security.Tls tls = 1;
- hasTrace() - Method in class io.grpc.channelz.v1.ChannelData.Builder
-
A trace of recent events on the channel.
- hasTrace() - Method in class io.grpc.channelz.v1.ChannelData
-
A trace of recent events on the channel.
- hasTrace() - Method in interface io.grpc.channelz.v1.ChannelDataOrBuilder
-
A trace of recent events on the channel.
- hasTrace() - Method in class io.grpc.channelz.v1.ServerData.Builder
-
A trace of recent events on the server.
- hasTrace() - Method in class io.grpc.channelz.v1.ServerData
-
A trace of recent events on the server.
- hasTrace() - Method in interface io.grpc.channelz.v1.ServerDataOrBuilder
-
A trace of recent events on the server.
- hasTrailer() - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
.grpc.binarylog.v1.Trailer trailer = 9;
- hasTrailer() - Method in class io.grpc.binarylog.v1.GrpcLogEntry
-
.grpc.binarylog.v1.Trailer trailer = 9;
- hasTrailer() - Method in interface io.grpc.binarylog.v1.GrpcLogEntryOrBuilder
-
.grpc.binarylog.v1.Trailer trailer = 9;
- hasUdsAddress() - Method in class io.grpc.channelz.v1.Address.Builder
-
.grpc.channelz.v1.Address.UdsAddress uds_address = 2;
- hasUdsAddress() - Method in class io.grpc.channelz.v1.Address
-
.grpc.channelz.v1.Address.UdsAddress uds_address = 2;
- hasUdsAddress() - Method in interface io.grpc.channelz.v1.AddressOrBuilder
-
.grpc.channelz.v1.Address.UdsAddress uds_address = 2;
- hasValue() - Method in class io.grpc.channelz.v1.Address.OtherAddress.Builder
-
The actual address message.
- hasValue() - Method in class io.grpc.channelz.v1.Address.OtherAddress
-
The actual address message.
- hasValue() - Method in interface io.grpc.channelz.v1.Address.OtherAddressOrBuilder
-
The actual address message.
- hasValue() - Method in class io.grpc.channelz.v1.Security.OtherSecurity.Builder
-
The actual security details message.
- hasValue() - Method in class io.grpc.channelz.v1.Security.OtherSecurity
-
The actual security details message.
- hasValue() - Method in interface io.grpc.channelz.v1.Security.OtherSecurityOrBuilder
-
The actual security details message.
- hasValue() - Method in class io.grpc.StatusOr
-
Returns whether there is a value.
- hcState - Variable in class io.grpc.protobuf.services.HealthCheckingLoadBalancerFactory.SubchannelImpl
- hcStates - Variable in class io.grpc.protobuf.services.HealthCheckingLoadBalancerFactory.HelperImpl
- HcStream() - Constructor for class io.grpc.protobuf.services.HealthCheckingLoadBalancerFactory.HealthCheckState.HcStream
- HEADER - Enum constant in enum io.grpc.internal.GzipInflatingBuffer.State
- HEADER - Enum constant in enum io.grpc.internal.MessageDeframer.State
- HEADER_COMMENT - Enum constant in enum io.grpc.internal.GzipInflatingBuffer.State
- HEADER_COMMENT_FLAG - Static variable in class io.grpc.internal.GzipInflatingBuffer
- HEADER_CRC - Enum constant in enum io.grpc.internal.GzipInflatingBuffer.State
- HEADER_CRC_FLAG - Static variable in class io.grpc.internal.GzipInflatingBuffer
- HEADER_DATA_FIELD_NUMBER - Static variable in class io.grpc.lookup.v1.RouteLookupResponse
- HEADER_EXTRA - Enum constant in enum io.grpc.internal.GzipInflatingBuffer.State
- HEADER_EXTRA_FLAG - Static variable in class io.grpc.internal.GzipInflatingBuffer
- HEADER_EXTRA_LEN - Enum constant in enum io.grpc.internal.GzipInflatingBuffer.State
- HEADER_LENGTH - Static variable in class io.grpc.internal.MessageDeframer
- HEADER_LENGTH - Static variable in class io.grpc.internal.MessageFramer
- HEADER_NAME - Enum constant in enum io.grpc.internal.GzipInflatingBuffer.State
- HEADER_NAME_FLAG - Static variable in class io.grpc.internal.GzipInflatingBuffer
- HeaderAttachingClientCall(ClientCall<ReqT, RespT>) - Constructor for class io.grpc.stub.MetadataUtils.HeaderAttachingClientInterceptor.HeaderAttachingClientCall
- HeaderAttachingClientInterceptor(Metadata) - Constructor for class io.grpc.stub.MetadataUtils.HeaderAttachingClientInterceptor
- headerCount() - Method in class io.grpc.Metadata
-
Returns the total number of key-value headers in this metadata, including duplicates.
- headerCount(Metadata) - Static method in class io.grpc.InternalMetadata
- headerData_ - Variable in class io.grpc.lookup.v1.RouteLookupResponse.Builder
- headerData_ - Variable in class io.grpc.lookup.v1.RouteLookupResponse
- headerExtraToRead - Variable in class io.grpc.internal.GzipInflatingBuffer
- headers - Variable in class io.grpc.inprocess.InProcessTransport.InProcessStream
- headers - Variable in class io.grpc.internal.AbstractClientStream.GetFramer
- headers - Variable in class io.grpc.internal.AbstractClientStream
- headers - Variable in class io.grpc.internal.PickSubchannelArgsImpl
- headers - Variable in class io.grpc.internal.RetriableStream
- headers - Variable in class io.grpc.netty.CreateStreamCommand
- headers - Variable in class io.grpc.netty.SendResponseHeadersCommand
- headers - Variable in class io.grpc.rls.AutoValue_RlsProtoData_GrpcKeyBuilder
- headers() - Method in class io.grpc.netty.CreateStreamCommand
- headers() - Method in class io.grpc.netty.SendResponseHeadersCommand
- headers() - Method in class io.grpc.rls.AutoValue_RlsProtoData_GrpcKeyBuilder
- headers() - Method in class io.grpc.rls.RlsProtoData.GrpcKeyBuilder
-
Returns a list of NameMatchers for header.
- headers_ - Variable in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
- headers_ - Variable in class io.grpc.lookup.v1.GrpcKeyBuilder
- headers_ - Variable in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
- headers_ - Variable in class io.grpc.lookup.v1.HttpKeyBuilder
- HEADERS_FIELD_NUMBER - Static variable in class io.grpc.lookup.v1.GrpcKeyBuilder
- HEADERS_FIELD_NUMBER - Static variable in class io.grpc.lookup.v1.HttpKeyBuilder
- headersBuilder_ - Variable in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
- headersBuilder_ - Variable in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
- headersCapture - Variable in class io.grpc.stub.MetadataUtils.MetadataCapturingClientInterceptor
- headerScratch - Variable in class io.grpc.internal.MessageFramer
- headersRead(Metadata) - Method in class io.grpc.internal.ClientCallImpl.ClientStreamListenerImpl
- headersRead(Metadata) - Method in interface io.grpc.internal.ClientStreamListener
-
Called upon receiving all header information from the remote end-point.
- headersRead(Metadata) - Method in class io.grpc.internal.DelayedStream.DelayedStreamListener
- headersRead(Metadata) - Method in class io.grpc.internal.ForwardingClientStreamListener
- headersRead(Metadata) - Method in class io.grpc.internal.RetriableStream.Sublistener
- headersReceived - Variable in class io.grpc.internal.Http2ClientStreamTransportState
- headersSent - Variable in class io.grpc.grpclb.GrpclbClientLoadRecorder.StreamTracer
- headersSent - Variable in class io.grpc.internal.AbstractServerStream
- headersSent - Variable in class io.grpc.stub.MetadataUtils.MetadataAttachingServerInterceptor.MetadataAttachingServerCall
- HEALTH_CONSUMER_LISTENER_ARG_KEY - Static variable in class io.grpc.LoadBalancer
- HealthBaseDescriptorSupplier() - Constructor for class io.grpc.health.v1.HealthGrpc.HealthBaseDescriptorSupplier
- HealthBlockingStub(Channel, CallOptions) - Constructor for class io.grpc.health.v1.HealthGrpc.HealthBlockingStub
- healthCheckedService - Variable in class io.grpc.protobuf.services.HealthCheckingLoadBalancerFactory.HelperImpl
- healthCheckingConfig - Variable in class io.grpc.internal.ManagedChannelServiceConfig
- HealthCheckingLoadBalancer(HealthCheckingLoadBalancerFactory.HelperImpl, LoadBalancer) - Constructor for class io.grpc.protobuf.services.HealthCheckingLoadBalancerFactory.HealthCheckingLoadBalancer
- HealthCheckingLoadBalancerFactory - Class in io.grpc.protobuf.services
-
Wraps a
LoadBalancer
and implements the client-side health-checking (https://github.com/grpc/proposal/blob/master/A17-client-side-health-checking.md). - HealthCheckingLoadBalancerFactory(LoadBalancer.Factory, BackoffPolicy.Provider, Supplier<Stopwatch>) - Constructor for class io.grpc.protobuf.services.HealthCheckingLoadBalancerFactory
- HealthCheckingLoadBalancerFactory.HealthCheckingLoadBalancer - Class in io.grpc.protobuf.services
- HealthCheckingLoadBalancerFactory.HealthCheckState - Class in io.grpc.protobuf.services
- HealthCheckingLoadBalancerFactory.HealthCheckState.HcStream - Class in io.grpc.protobuf.services
- HealthCheckingLoadBalancerFactory.HelperImpl - Class in io.grpc.protobuf.services
- HealthCheckingLoadBalancerFactory.SubchannelImpl - Class in io.grpc.protobuf.services
- HealthCheckingLoadBalancerUtil - Class in io.grpc.protobuf.services
-
Utility for enabling client-side health checking for
LoadBalancer
s. - HealthCheckingLoadBalancerUtil() - Constructor for class io.grpc.protobuf.services.HealthCheckingLoadBalancerUtil
- HealthCheckingRoundRobinLoadBalancerProvider - Class in io.grpc.protobuf.services.internal
-
The health-check-capable provider for the "round_robin" balancing policy.
- HealthCheckingRoundRobinLoadBalancerProvider() - Constructor for class io.grpc.protobuf.services.internal.HealthCheckingRoundRobinLoadBalancerProvider
- HealthCheckRequest - Class in io.grpc.health.v1
-
Protobuf type
grpc.health.v1.HealthCheckRequest
- HealthCheckRequest() - Constructor for class io.grpc.health.v1.HealthCheckRequest
- HealthCheckRequest(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.health.v1.HealthCheckRequest
- HealthCheckRequest.Builder - Class in io.grpc.health.v1
-
Protobuf type
grpc.health.v1.HealthCheckRequest
- HealthCheckRequestOrBuilder - Interface in io.grpc.health.v1
- HealthCheckResponse - Class in io.grpc.health.v1
-
Protobuf type
grpc.health.v1.HealthCheckResponse
- HealthCheckResponse() - Constructor for class io.grpc.health.v1.HealthCheckResponse
- HealthCheckResponse(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.health.v1.HealthCheckResponse
- HealthCheckResponse.Builder - Class in io.grpc.health.v1
-
Protobuf type
grpc.health.v1.HealthCheckResponse
- HealthCheckResponse.ServingStatus - Enum in io.grpc.health.v1
-
Protobuf enum
grpc.health.v1.HealthCheckResponse.ServingStatus
- HealthCheckResponseOrBuilder - Interface in io.grpc.health.v1
- HealthCheckState(HealthCheckingLoadBalancerFactory.HelperImpl, SynchronizationContext, ScheduledExecutorService, LoadBalancer.SubchannelStateListener) - Constructor for class io.grpc.protobuf.services.HealthCheckingLoadBalancerFactory.HealthCheckState
- HealthFileDescriptorSupplier() - Constructor for class io.grpc.health.v1.HealthGrpc.HealthFileDescriptorSupplier
- HealthFutureStub(Channel, CallOptions) - Constructor for class io.grpc.health.v1.HealthGrpc.HealthFutureStub
- HealthGrpc - Class in io.grpc.health.v1
- HealthGrpc() - Constructor for class io.grpc.health.v1.HealthGrpc
- HealthGrpc.AsyncService - Interface in io.grpc.health.v1
- HealthGrpc.HealthBaseDescriptorSupplier - Class in io.grpc.health.v1
- HealthGrpc.HealthBlockingStub - Class in io.grpc.health.v1
-
A stub to allow clients to do synchronous rpc calls to service Health.
- HealthGrpc.HealthFileDescriptorSupplier - Class in io.grpc.health.v1
- HealthGrpc.HealthFutureStub - Class in io.grpc.health.v1
-
A stub to allow clients to do ListenableFuture-style rpc calls to service Health.
- HealthGrpc.HealthImplBase - Class in io.grpc.health.v1
-
Base class for the server implementation of the service Health.
- HealthGrpc.HealthMethodDescriptorSupplier - Class in io.grpc.health.v1
- HealthGrpc.HealthStub - Class in io.grpc.health.v1
-
A stub to allow clients to do asynchronous rpc calls to service Health.
- HealthGrpc.MethodHandlers<Req,
Resp> - Class in io.grpc.health.v1 - HealthImplBase() - Constructor for class io.grpc.health.v1.HealthGrpc.HealthImplBase
- healthListener - Variable in class io.grpc.util.HealthProducerHelper.HealthProducerSubchannel
- HealthListener() - Constructor for class io.grpc.internal.PickFirstLeafLoadBalancer.HealthListener
- HealthMethodDescriptorSupplier(String) - Constructor for class io.grpc.health.v1.HealthGrpc.HealthMethodDescriptorSupplier
- HealthProducerHelper - Class in io.grpc.util
-
A new
LoadBalancer.Helper
used by health producer systems to build health notification chain, viaLoadBalancer.CreateSubchannelArgs
. - HealthProducerHelper(LoadBalancer.Helper) - Constructor for class io.grpc.util.HealthProducerHelper
- HealthProducerHelper.HealthProducerSubchannel - Class in io.grpc.util
- HealthProducerSubchannel(LoadBalancer.Subchannel, LoadBalancer.SubchannelStateListener) - Constructor for class io.grpc.util.HealthProducerHelper.HealthProducerSubchannel
- HealthProto - Class in io.grpc.health.v1
- HealthProto() - Constructor for class io.grpc.health.v1.HealthProto
- healthService - Variable in class io.grpc.protobuf.services.HealthStatusManager
- HealthServiceImpl - Class in io.grpc.protobuf.services
- HealthServiceImpl() - Constructor for class io.grpc.protobuf.services.HealthServiceImpl
- healthStateInfo - Variable in class io.grpc.internal.PickFirstLeafLoadBalancer.SubchannelData
- HealthStatusManager - Class in io.grpc.protobuf.services
-
A
HealthStatusManager
object manages a health check service. - HealthStatusManager - Class in io.grpc.services
-
Deprecated.Use
HealthStatusManager
instead. - HealthStatusManager() - Constructor for class io.grpc.protobuf.services.HealthStatusManager
-
Creates a new health service instance.
- HealthStatusManager() - Constructor for class io.grpc.services.HealthStatusManager
-
Deprecated.Creates a new health service instance.
- HealthStub(Channel, CallOptions) - Constructor for class io.grpc.health.v1.HealthGrpc.HealthStub
- hedgingAttemptCount - Variable in class io.grpc.internal.RetriableStream.State
- hedgingDelayNanos - Variable in class io.grpc.internal.HedgingPolicy
- hedgingFrozen - Variable in class io.grpc.internal.RetriableStream.State
-
No more hedging due to events like drop or pushback.
- HedgingPlan(boolean, Integer) - Constructor for class io.grpc.internal.RetriableStream.HedgingPlan
- hedgingPolicy - Variable in class io.grpc.internal.ManagedChannelServiceConfig.MethodInfo
- hedgingPolicy - Variable in class io.grpc.internal.RetriableStream
- hedgingPolicy(Map<String, ?>, int) - Static method in class io.grpc.internal.ManagedChannelServiceConfig.MethodInfo
- HedgingPolicy - Class in io.grpc.internal
-
Hedging policy data object.
- HedgingPolicy(int, long, Set<Status.Code>) - Constructor for class io.grpc.internal.HedgingPolicy
-
The caller is supposed to have validated the arguments and handled throwing exception or logging warnings already, so we avoid repeating args check here.
- hedgingPushbackMillis - Variable in class io.grpc.internal.RetriableStream.HedgingPlan
- HedgingRunnable(RetriableStream.FutureCanceller) - Constructor for class io.grpc.internal.RetriableStream.HedgingRunnable
- helper - Variable in class io.grpc.grpclb.CachedSubchannelPool
- helper - Variable in class io.grpc.grpclb.GrpclbLoadBalancer
- helper - Variable in class io.grpc.grpclb.GrpclbState
- helper - Variable in class io.grpc.internal.AutoConfiguredLoadBalancerFactory.AutoConfiguredLoadBalancer
- helper - Variable in class io.grpc.internal.ManagedChannelImpl.NameResolverListener
- helper - Variable in class io.grpc.internal.PickFirstLeafLoadBalancer
- helper - Variable in class io.grpc.internal.PickFirstLoadBalancer
- helper - Variable in class io.grpc.protobuf.services.HealthCheckingLoadBalancerFactory.HealthCheckingLoadBalancer
- helper - Variable in class io.grpc.rls.CachingRlsLbClient.Builder
- helper - Variable in class io.grpc.rls.CachingRlsLbClient
- helper - Variable in class io.grpc.rls.CachingRlsLbClient.RlsAsyncLruCache
- helper - Variable in class io.grpc.rls.CachingRlsLbClient.RlsLbHelper
- helper - Variable in class io.grpc.rls.ChildLoadBalancerHelper.ChildLoadBalancerHelperProvider
- helper - Variable in class io.grpc.rls.LbPolicyConfiguration.ChildPolicyWrapper
- helper - Variable in class io.grpc.rls.RlsLoadBalancer
- helper - Variable in class io.grpc.util.GracefulSwitchLoadBalancer
- helper - Variable in class io.grpc.util.MultiChildLoadBalancer
- Helper() - Constructor for class io.grpc.LoadBalancer.Helper
- helperImpl - Variable in class io.grpc.protobuf.services.HealthCheckingLoadBalancerFactory.HealthCheckState
- HelperImpl(LoadBalancer.Helper) - Constructor for class io.grpc.protobuf.services.HealthCheckingLoadBalancerFactory.HelperImpl
- HEX - Static variable in class io.grpc.Status.StatusMessageMarshaller
- hextetsToIPv6String(int[]) - Static method in class io.grpc.protobuf.services.InetAddressUtil
- historySeconds - Variable in class io.grpc.rls.AdaptiveThrottler.Builder
- historySeconds - Variable in class io.grpc.rls.AdaptiveThrottler
-
The duration of history of calls used by Adaptive Throttler.
- holder - Static variable in class io.grpc.internal.SharedResourceHolder
- host - Variable in class io.grpc.internal.DnsNameResolver
- host - Variable in class io.grpc.internal.DnsNameResolver.SrvRecord
- host - Variable in class io.grpc.netty.ProtocolNegotiators.ClientTlsHandler
- host - Variable in class io.grpc.netty.ProtocolNegotiators.HostPort
- host - Variable in class io.grpc.rls.AutoValue_RlsProtoData_ExtraKeys
- host() - Method in class io.grpc.rls.AutoValue_RlsProtoData_ExtraKeys
- host() - Method in class io.grpc.rls.RlsProtoData.ExtraKeys
- host_ - Variable in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys.Builder
- host_ - Variable in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys
- host_ - Variable in class io.grpc.reflection.v1.ServerReflectionRequest.Builder
- host_ - Variable in class io.grpc.reflection.v1.ServerReflectionRequest
- host_ - Variable in class io.grpc.reflection.v1alpha.ServerReflectionRequest.Builder
- host_ - Variable in class io.grpc.reflection.v1alpha.ServerReflectionRequest
- HOST_FIELD_NUMBER - Static variable in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys
- HOST_FIELD_NUMBER - Static variable in class io.grpc.reflection.v1.ServerReflectionRequest
- HOST_FIELD_NUMBER - Static variable in class io.grpc.reflection.v1alpha.ServerReflectionRequest
- HOST_PATTERNS_FIELD_NUMBER - Static variable in class io.grpc.lookup.v1.HttpKeyBuilder
- hostPatterns_ - Variable in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
- hostPatterns_ - Variable in class io.grpc.lookup.v1.HttpKeyBuilder
- HostPort(String, int) - Constructor for class io.grpc.netty.ProtocolNegotiators.HostPort
- How Proxies work in gRPC - Search tag in interface io.grpc.ProxyDetector
- Section
- HTTP - Static variable in class io.grpc.netty.Utils
- HTTP_1_1_REQUIRED - Enum constant in enum io.grpc.internal.GrpcUtil.Http2Error
- HTTP_GET_METHOD - Static variable in class io.grpc.netty.Utils
- HTTP_KEYBUILDERS_FIELD_NUMBER - Static variable in class io.grpc.lookup.v1.RouteLookupConfig
- HTTP_METHOD - Static variable in class io.grpc.internal.GrpcUtil
-
The HTTP method used for GRPC requests.
- HTTP_METHOD - Static variable in class io.grpc.netty.Utils
- HTTP_STATUS_MARSHALLER - Static variable in class io.grpc.internal.Http2ClientStreamTransportState
-
Metadata marshaller for HTTP status lines.
- HTTP2_STATUS - Static variable in class io.grpc.internal.Http2ClientStreamTransportState
- HTTP2_VERSION - Static variable in class io.grpc.netty.GrpcSslContexts
- Http2ClientStreamTransportState - Class in io.grpc.internal
-
Base implementation for client streams using HTTP2 as the transport.
- Http2ClientStreamTransportState(int, StatsTraceContext, TransportTracer, CallOptions) - Constructor for class io.grpc.internal.Http2ClientStreamTransportState
- Http2ControlFrameLimitEncoder - Class in io.grpc.netty
-
DecoratingHttp2ConnectionEncoder
which guards against a remote peer that will trigger a massive amount of control frames but will not consume our responses to these. - Http2ControlFrameLimitEncoder(Http2ConnectionEncoder, int) - Constructor for class io.grpc.netty.Http2ControlFrameLimitEncoder
- Http2Error(int, Status) - Constructor for enum io.grpc.internal.GrpcUtil.Http2Error
- Http2Ping - Class in io.grpc.internal
-
Represents an outstanding PING operation on an HTTP/2 channel.
- Http2Ping(long, Stopwatch) - Constructor for class io.grpc.internal.Http2Ping
-
Creates a new ping operation.
- http2ProcessingFailed(Status) - Method in class io.grpc.netty.NettyServerStream.TransportState
-
Called to process a failure in HTTP/2 processing.
- http2ProcessingFailed(Status, boolean, Metadata) - Method in class io.grpc.internal.Http2ClientStreamTransportState
-
Called to process a failure in HTTP/2 processing.
- http2ProcessingFailed(Status, boolean, Metadata) - Method in class io.grpc.netty.NettyClientStream.TransportState
- http2Stream - Variable in class io.grpc.netty.NettyClientStream.TransportState
- http2Stream - Variable in class io.grpc.netty.NettyServerStream.TransportState
- http2Stream() - Method in class io.grpc.netty.NettyClientStream.TransportState
-
Gets the underlying Netty
Http2Stream
for this stream. - Http2UpgradeAndGrpcHandler(String, GrpcHttp2ConnectionHandler) - Constructor for class io.grpc.netty.ProtocolNegotiators.Http2UpgradeAndGrpcHandler
- HttpConnectProxiedSocketAddress - Class in io.grpc
-
An
ProxiedSocketAddress
for making a connection to an endpoint via an HTTP CONNECT proxy. - HttpConnectProxiedSocketAddress(SocketAddress, InetSocketAddress, String, String) - Constructor for class io.grpc.HttpConnectProxiedSocketAddress
- HttpConnectProxiedSocketAddress.Builder - Class in io.grpc
-
The builder for
HttpConnectProxiedSocketAddress
. - HttpKeyBuilder - Class in io.grpc.lookup.v1
-
An HttpKeyBuilder applies to a given HTTP URL and headers.
- HttpKeyBuilder() - Constructor for class io.grpc.lookup.v1.HttpKeyBuilder
- HttpKeyBuilder(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.lookup.v1.HttpKeyBuilder
- HttpKeyBuilder.Builder - Class in io.grpc.lookup.v1
-
An HttpKeyBuilder applies to a given HTTP URL and headers.
- HttpKeyBuilder.ConstantKeysDefaultEntryHolder - Class in io.grpc.lookup.v1
- HttpKeyBuilderOrBuilder - Interface in io.grpc.lookup.v1
- httpKeybuilders_ - Variable in class io.grpc.lookup.v1.RouteLookupConfig.Builder
- httpKeybuilders_ - Variable in class io.grpc.lookup.v1.RouteLookupConfig
- httpKeybuildersBuilder_ - Variable in class io.grpc.lookup.v1.RouteLookupConfig.Builder
- httpProxy(SocketAddress, String, String, ProtocolNegotiator) - Static method in class io.grpc.netty.ProtocolNegotiators
-
Returns a
ProtocolNegotiator
that does HTTP CONNECT proxy negotiation. - HTTPS - Static variable in class io.grpc.netty.Utils
- httpStatusToGrpcCode(int) - Static method in class io.grpc.internal.GrpcUtil
- httpStatusToGrpcStatus(int) - Static method in class io.grpc.internal.GrpcUtil
-
Maps HTTP error response status codes to transport codes, as defined in http-grpc-status-mapping.md.
I
- IBM_PROVIDER_NAME - Static variable in class io.grpc.netty.GrpcSslContexts
- id - Variable in class io.grpc.InternalLogId
- id - Variable in class io.grpc.netty.NettyClientStream.TransportState
- id - Variable in class io.grpc.netty.NettyServer.ListenSocket
- id() - Method in class io.grpc.netty.NettyClientStream.TransportState
- id() - Method in class io.grpc.netty.NettyServerStream.TransportState
- id() - Method in interface io.grpc.netty.StreamIdHolder
-
Returns the id.
- id(InternalWithLogId) - Static method in class io.grpc.InternalChannelz
-
Unwraps a
InternalLogId
to return along
. - idAlloc - Static variable in class io.grpc.InternalLogId
- idempotent - Variable in class io.grpc.MethodDescriptor.Builder
- idempotent - Variable in class io.grpc.MethodDescriptor
- Identity() - Constructor for class io.grpc.Codec.Identity
- IDLE - Enum constant in enum io.grpc.channelz.v1.ChannelConnectivityState.State
-
IDLE = 1;
- IDLE - Enum constant in enum io.grpc.ConnectivityState
-
This is the state where the channel is not even trying to create a connection because of a lack of new or pending RPCs.
- IDLE - Enum constant in enum io.grpc.internal.KeepAliveManager.State
- IDLE_AND_PING_SENT - Enum constant in enum io.grpc.internal.KeepAliveManager.State
- IDLE_MODE_DEFAULT_TIMEOUT_MILLIS - Static variable in class io.grpc.internal.ManagedChannelImplBuilder
-
The default idle timeout.
- IDLE_MODE_MAX_TIMEOUT_DAYS - Static variable in class io.grpc.internal.ManagedChannelImplBuilder
-
An idle timeout larger than this would disable idle mode.
- IDLE_MODE_MIN_TIMEOUT_MILLIS - Static variable in class io.grpc.internal.ManagedChannelImplBuilder
-
An idle timeout smaller than this would be capped to it.
- IDLE_TIMEOUT_MILLIS_DISABLE - Static variable in class io.grpc.internal.ManagedChannelImpl
- IDLE_VALUE - Static variable in enum io.grpc.channelz.v1.ChannelConnectivityState.State
-
IDLE = 1;
- IdleModeStateAggregator() - Constructor for class io.grpc.internal.ManagedChannelImpl.IdleModeStateAggregator
- IdleModeTimer() - Constructor for class io.grpc.internal.ManagedChannelImpl.IdleModeTimer
- IdleSubchannelEntry(LoadBalancer.Subchannel, SynchronizationContext) - Constructor for class io.grpc.grpclb.GrpclbState.IdleSubchannelEntry
- idleTimeout(long, TimeUnit) - Method in class io.grpc.ForwardingChannelBuilder
- idleTimeout(long, TimeUnit) - Method in class io.grpc.ForwardingChannelBuilder2
- idleTimeout(long, TimeUnit) - Method in class io.grpc.internal.ManagedChannelImplBuilder
- idleTimeout(long, TimeUnit) - Method in class io.grpc.ManagedChannelBuilder
-
Set the duration without ongoing RPCs before going to idle mode.
- idleTimeoutMillis - Variable in class io.grpc.internal.ManagedChannelImpl
-
The timeout before entering idle mode.
- idleTimeoutMillis - Variable in class io.grpc.internal.ManagedChannelImplBuilder
- idleTimer - Variable in class io.grpc.internal.ManagedChannelImpl
- idx - Variable in class io.grpc.netty.GrpcHttp2OutboundHeaders.Itr
- ignoreClose(ReadableBuffer) - Static method in class io.grpc.internal.ReadableBuffers
-
Decorates the given
ReadableBuffer
to ignore calls toReadableBuffer.close()
. - ignoreRefreshNameResolutionCheck() - Method in class io.grpc.LoadBalancer.Helper
-
Deprecated.Warning has been removed
- ignoreRefreshNameResolutionCheck() - Method in class io.grpc.util.ForwardingLoadBalancerHelper
-
Deprecated.
- immediateCloseRequested - Variable in class io.grpc.internal.AbstractServerStream.TransportState
- immutableServicesIndex - Variable in class io.grpc.protobuf.services.ProtoReflectionServiceV1.ServerReflectionIndex
- IMPLEMENTATION_VERSION - Static variable in class io.grpc.internal.GrpcUtil
- implementationVersion - Variable in class io.grpc.internal.GrpcUtil.GrpcBuildVersion
- IMPLICIT_PERMIT_TIME_NANOS - Static variable in class io.grpc.internal.KeepAliveEnforcer
- inactiveCallCounter - Variable in class io.grpc.util.OutlierDetectionLoadBalancer.EndpointTracker
- inactiveVolume() - Method in class io.grpc.util.OutlierDetectionLoadBalancer.EndpointTracker
- INADEQUATE_SECURITY - Enum constant in enum io.grpc.internal.GrpcUtil.Http2Error
- INAPPROPRIATE_CONTROL_PLANE_STATUS - Static variable in class io.grpc.internal.GrpcUtil
- inboundBodyWireSize - Variable in class io.grpc.internal.MessageDeframer
- 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.
- inboundDataReceived(ByteBuf, boolean) - Method in class io.grpc.netty.NettyServerStream.TransportState
- inboundHeaders() - Method in class io.grpc.ClientStreamTracer
-
Headers has been received from the server.
- inboundHeaders() - Method in class io.grpc.grpclb.GrpclbClientLoadRecorder.StreamTracer
- inboundHeaders() - Method in class io.grpc.internal.ForwardingClientStreamTracer
- inboundHeaders() - Method in class io.grpc.util.ForwardingClientStreamTracer
- inboundHeaders(Metadata) - Method in class io.grpc.ClientStreamTracer
-
Headers has been received from the server.
- inboundHeaders(Metadata) - Method in class io.grpc.internal.ForwardingClientStreamTracer
- inboundHeaders(Metadata) - Method in class io.grpc.util.ForwardingClientStreamTracer
- inboundHeadersReceived(Metadata) - Method in class io.grpc.internal.AbstractClientStream.TransportState
-
Called by transport implementations when they receive headers.
- inboundMessage(int) - Method in class io.grpc.grpclb.GrpclbClientLoadRecorder.StreamTracer
- inboundMessage(int) - Method in class io.grpc.internal.ForwardingClientStreamTracer
- 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.
- inboundMessage(int) - Method in class io.grpc.util.ForwardingClientStreamTracer
- inboundMessageRead(int, long, long) - Method in class io.grpc.internal.ForwardingClientStreamTracer
- 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.
- inboundMessageRead(int, long, long) - Method in class io.grpc.util.ForwardingClientStreamTracer
- inboundTrailers(Metadata) - Method in class io.grpc.ClientStreamTracer
-
Trailing metadata has been received from the server.
- inboundTrailers(Metadata) - Method in class io.grpc.internal.ForwardingClientStreamTracer
- inboundTrailers(Metadata) - Method in class io.grpc.util.ForwardingClientStreamTracer
- inboundTrailersReceived(Metadata, Status) - Method in class io.grpc.internal.AbstractClientStream.TransportState
-
Processes the trailers and status from the server.
- inboundUncompressedSize(long) - Method in class io.grpc.internal.ForwardingClientStreamTracer
- 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.
- inboundUncompressedSize(long) - Method in class io.grpc.util.ForwardingClientStreamTracer
- inboundWireSize(long) - Method in class io.grpc.internal.ForwardingClientStreamTracer
- 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.
- inboundWireSize(long) - Method in class io.grpc.util.ForwardingClientStreamTracer
- includeCauseWithStatus - Variable in class io.grpc.inprocess.InProcessChannelBuilder.InProcessClientTransportFactory
- includeCauseWithStatus - Variable in class io.grpc.inprocess.InProcessTransport
- incomprehensible(Set<TlsChannelCredentials.Feature>) - Method in class io.grpc.TlsChannelCredentials
-
Returns an empty set if this credential can be adequately understood via the features listed, otherwise returns a hint of features that are lacking to understand the configuration to be used for manual debugging.
- incomprehensible(Set<TlsServerCredentials.Feature>) - Method in class io.grpc.TlsServerCredentials
-
Returns an empty set if this credential can be adequately understood via the features listed, otherwise returns a hint of features that are lacking to understand the configuration to be used for manual debugging.
- increment() - Method in class io.grpc.internal.InternalSubchannel.Index
- increment() - Method in class io.grpc.internal.PickFirstLeafLoadBalancer.Index
-
Move to next address in group.
- increment() - Method in class io.grpc.rls.AdaptiveThrottler.TimeBasedAccumulator.Slot
- increment(long) - Method in class io.grpc.rls.AdaptiveThrottler.TimeBasedAccumulator
-
Increments the count of the statistic by the specified amount for the specified time.
- incrementAndGetNextStreamId() - Method in class io.grpc.netty.NettyClientHandler
- incrementCallCount(boolean) - Method in class io.grpc.util.OutlierDetectionLoadBalancer.EndpointTracker
- incrementDataSincePing(int) - Method in class io.grpc.netty.AbstractNettyHandler.FlowControlPinger
- inDelivery - Variable in class io.grpc.internal.MessageDeframer
- index - Variable in class io.grpc.PartialMetricInstrument
- index - Variable in class io.grpc.servlet.jakarta.ServletServerStream.ByteArrayWritableBuffer
- index - Variable in class io.grpc.servlet.ServletServerStream.ByteArrayWritableBuffer
- index - Variable in class io.grpc.util.RoundRobinLoadBalancer.ReadyPicker
- Index(List<EquivalentAddressGroup>) - Constructor for class io.grpc.internal.InternalSubchannel.Index
- Index(List<EquivalentAddressGroup>) - Constructor for class io.grpc.internal.PickFirstLeafLoadBalancer.Index
- indexBit(int, int) - Static method in class io.grpc.PersistentHashArrayMappedTrie.CompressedIndex
- indexOfKey(K) - Method in class io.grpc.PersistentHashArrayMappedTrie.CollisionLeaf
- InetAddressUtil - Class in io.grpc.protobuf.services
- InetAddressUtil() - Constructor for class io.grpc.protobuf.services.InetAddressUtil
- inflate(byte[], int, int) - Method in class io.grpc.internal.GzipInflatingBuffer
- INFLATE_BUFFER_SIZE - Static variable in class io.grpc.internal.GzipInflatingBuffer
- inflateBytes(byte[], int, int) - Method in class io.grpc.internal.GzipInflatingBuffer
-
Attempts to inflate
length
bytes of data intob
. - inflatedBuffer - Variable in class io.grpc.internal.MessageDeframer
- inflatedIndex - Variable in class io.grpc.internal.MessageDeframer
- inflater - Variable in class io.grpc.internal.GzipInflatingBuffer
- INFLATER_NEEDS_INPUT - Enum constant in enum io.grpc.internal.GzipInflatingBuffer.State
- inflaterInput - Variable in class io.grpc.internal.GzipInflatingBuffer
- inflaterInputEnd - Variable in class io.grpc.internal.GzipInflatingBuffer
- inflaterInputStart - Variable in class io.grpc.internal.GzipInflatingBuffer
- INFLATING - Enum constant in enum io.grpc.internal.GzipInflatingBuffer.State
- inFlightSubStreams - Variable in class io.grpc.internal.RetriableStream
- INFO - Enum constant in enum io.grpc.ChannelLogger.ChannelLogLevel
- init() - Method in class io.grpc.internal.ServerImpl.ServerTransportListenerImpl
- init() - Method in class io.grpc.rls.CachingRlsLbClient
- init() - Method in class io.grpc.rls.ChildLoadBalancerHelper.ChildLoadBalancerHelperProvider
- init() - Method in class io.grpc.rls.LbPolicyConfiguration.RefCountedChildPolicyWrapperFactory
- init(LoadBalancer.SubchannelStateListener) - Method in class io.grpc.protobuf.services.HealthCheckingLoadBalancerFactory.HealthCheckState
- INITIAL_INSTRUMENT_CAPACITY - Static variable in class io.grpc.MetricInstrumentRegistry
- INITIAL_PENDING_SELECTOR - Static variable in class io.grpc.internal.ManagedChannelImpl
- INITIAL_REQUEST - Enum constant in enum io.grpc.lb.v1.LoadBalanceRequest.LoadBalanceRequestTypeCase
- INITIAL_REQUEST_FIELD_NUMBER - Static variable in class io.grpc.lb.v1.LoadBalanceRequest
- INITIAL_RESPONSE - Enum constant in enum io.grpc.lb.v1.LoadBalanceResponse.LoadBalanceResponseTypeCase
- INITIAL_RESPONSE_FIELD_NUMBER - Static variable in class io.grpc.lb.v1.LoadBalanceResponse
- initialBackoffNanos - Variable in class io.grpc.internal.ExponentialBackoffPolicy
- initialBackoffNanos - Variable in class io.grpc.internal.RetryPolicy
- initialConnectionWindow - Variable in class io.grpc.netty.AbstractNettyHandler
- initialDeadlineMonitor - Variable in class io.grpc.internal.DelayedClientCall
-
A timer to monitor the initial deadline.
- initialFlowControlWindow(int) - Method in class io.grpc.netty.NettyChannelBuilder
-
Sets the initial flow control window in bytes.
- initialFlowControlWindow(int) - Method in class io.grpc.netty.NettyServerBuilder
-
Sets the initial flow control window in bytes.
- initializationException - Static variable in class io.grpc.internal.ReflectionLongAdderCounter
- initialize() - Method in class io.grpc.internal.ApplicationThreadDeframer.InitializingMessageProducer
- INITIALIZE_INFLATER - Enum constant in enum io.grpc.internal.GzipInflatingBuffer.State
- initialized - Variable in class io.grpc.internal.ApplicationThreadDeframer.InitializingMessageProducer
- initializeInflater() - Method in class io.grpc.internal.GzipInflatingBuffer
- InitializingMessageProducer(Runnable) - Constructor for class io.grpc.internal.ApplicationThreadDeframer.InitializingMessageProducer
- InitialLoadBalanceRequest - Class in io.grpc.lb.v1
-
Protobuf type
grpc.lb.v1.InitialLoadBalanceRequest
- InitialLoadBalanceRequest() - Constructor for class io.grpc.lb.v1.InitialLoadBalanceRequest
- InitialLoadBalanceRequest(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.lb.v1.InitialLoadBalanceRequest
- InitialLoadBalanceRequest.Builder - Class in io.grpc.lb.v1
-
Protobuf type
grpc.lb.v1.InitialLoadBalanceRequest
- InitialLoadBalanceRequestOrBuilder - Interface in io.grpc.lb.v1
- InitialLoadBalanceResponse - Class in io.grpc.lb.v1
-
Protobuf type
grpc.lb.v1.InitialLoadBalanceResponse
- InitialLoadBalanceResponse() - Constructor for class io.grpc.lb.v1.InitialLoadBalanceResponse
- InitialLoadBalanceResponse(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.lb.v1.InitialLoadBalanceResponse
- InitialLoadBalanceResponse.Builder - Class in io.grpc.lb.v1
-
Protobuf type
grpc.lb.v1.InitialLoadBalanceResponse
- InitialLoadBalanceResponseOrBuilder - Interface in io.grpc.lb.v1
- initialRequest - Variable in class io.grpc.stub.ClientCalls.CallToStreamObserverAdapter
- initialRequestBuilder_ - Variable in class io.grpc.lb.v1.LoadBalanceRequest.Builder
- initialResponseBuilder_ - Variable in class io.grpc.lb.v1.LoadBalanceResponse.Builder
- initialResponseReceived - Variable in class io.grpc.grpclb.GrpclbState.LbStream
- initialWindowSent - Variable in class io.grpc.netty.AbstractNettyHandler
- initJndi() - Static method in class io.grpc.internal.JndiResourceResolverFactory
-
Returns whether the JNDI DNS resolver is available.
- InProcessChannelBuilder - Class in io.grpc.inprocess
-
Builder for a channel that issues in-process requests.
- InProcessChannelBuilder(SocketAddress, String) - Constructor for class io.grpc.inprocess.InProcessChannelBuilder
- InProcessChannelBuilder.InProcessClientTransportFactory - Class in io.grpc.inprocess
-
Creates InProcess transports.
- InProcessClientStream(CallOptions, StatsTraceContext) - Constructor for class io.grpc.inprocess.InProcessTransport.InProcessStream.InProcessClientStream
- InProcessClientTransportFactory(ScheduledExecutorService, int, boolean, long) - Constructor for class io.grpc.inprocess.InProcessChannelBuilder.InProcessClientTransportFactory
- InProcessServer - Class in io.grpc.inprocess
- InProcessServer(InProcessServerBuilder, List<? extends ServerStreamTracer.Factory>) - Constructor for class io.grpc.inprocess.InProcessServer
- InProcessServerBuilder - Class in io.grpc.inprocess
-
Builder for a server that services in-process requests.
- InProcessServerBuilder(SocketAddress) - Constructor for class io.grpc.inprocess.InProcessServerBuilder
- InProcessServerStream(MethodDescriptor<?, ?>, Metadata) - Constructor for class io.grpc.inprocess.InProcessTransport.InProcessStream.InProcessServerStream
- InProcessSocketAddress - Class in io.grpc.inprocess
-
Custom SocketAddress class for
InProcessTransport
. - InProcessSocketAddress(String) - Constructor for class io.grpc.inprocess.InProcessSocketAddress
-
Construct an address for a server identified by name.
- InProcessStream(MethodDescriptor<?, ?>, Metadata, CallOptions, String, StatsTraceContext) - Constructor for class io.grpc.inprocess.InProcessTransport.InProcessStream
- InProcessTransport - Class in io.grpc.inprocess
- InProcessTransport(SocketAddress, int, String, String, Attributes, boolean, long) - Constructor for class io.grpc.inprocess.InProcessTransport
- InProcessTransport.InProcessStream - Class in io.grpc.inprocess
- InProcessTransport.InProcessStream.InProcessClientStream - Class in io.grpc.inprocess
- InProcessTransport.InProcessStream.InProcessServerStream - Class in io.grpc.inprocess
- InProcessTransport.SingleMessageProducer - Class in io.grpc.inprocess
- input - Variable in class io.grpc.servlet.jakarta.ServletAdapter.GrpcReadListener
- input - Variable in class io.grpc.servlet.ServletAdapter.GrpcReadListener
- InsecureChannelCredentials - Class in io.grpc
-
No client identity, authentication, or encryption is to be used.
- InsecureChannelCredentials() - Constructor for class io.grpc.InsecureChannelCredentials
- InsecureFromHttp1ChannelCredentials - Class in io.grpc.netty
-
An insecure credential that upgrades from HTTP/1 to HTTP/2.
- InsecureFromHttp1ChannelCredentials() - Constructor for class io.grpc.netty.InsecureFromHttp1ChannelCredentials
- INSECURELY_SKIP_ALL_VERIFICATION - Enum constant in enum io.grpc.util.AdvancedTlsX509TrustManager.Verification
-
DANGEROUS: This SHOULD be used by advanced user intended to implement the entire verification logic themselves
AdvancedTlsX509TrustManager.SslSocketAndEnginePeerVerifier
) themselves. - InsecureServerCredentials - Class in io.grpc
-
No server identity or encryption is to be used.
- InsecureServerCredentials() - Constructor for class io.grpc.InsecureServerCredentials
- InsightBuilder - Class in io.grpc.internal
-
Builds a concise and readable string that gives insight of the concerned part of the system.
- InsightBuilder() - Constructor for class io.grpc.internal.InsightBuilder
- instance - Static variable in class io.grpc.ConfiguratorRegistry
- instance - Variable in class io.grpc.internal.ReflectionLongAdderCounter
- instance - Static variable in class io.grpc.LoadBalancerRegistry
- instance - Static variable in class io.grpc.ManagedChannelRegistry
- instance - Static variable in class io.grpc.MetricInstrumentRegistry
- instance - Static variable in class io.grpc.NameResolverRegistry
- instance - Static variable in class io.grpc.netty.NettySocketSupport
- instance - Static variable in class io.grpc.ServerRegistry
- instance() - Static method in class io.grpc.InternalChannelz
- instance() - Static method in class io.grpc.util.TransmitStatusRuntimeExceptionInterceptor
- Instance(Object) - Constructor for class io.grpc.internal.SharedResourceHolder.Instance
- INSTANCE - Enum constant in enum io.grpc.Context.DirectExecutor
- INSTANCE - Enum constant in enum io.grpc.internal.DnsNameResolver.JdkAddressResolver
- INSTANCE - Static variable in class io.grpc.internal.KeepAliveEnforcer.SystemTicker
- INSTANCE - Static variable in class io.grpc.internal.NoopClientStream
- INSTANCE - Static variable in class io.grpc.InternalChannelz
- instances - Variable in class io.grpc.internal.SharedResourceHolder
- INTEGRITY - Enum constant in enum io.grpc.SecurityLevel
-
The other party is authenticated and the data is not tampered with.
- intercept(BindableService, ServerInterceptor...) - Static method in class io.grpc.ServerInterceptors
- intercept(BindableService, List<? extends ServerInterceptor>) - Static method in class io.grpc.ServerInterceptors
- intercept(Channel, ClientInterceptor...) - Static method in class io.grpc.ClientInterceptors
-
Create a new
Channel
that will callinterceptors
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 callinterceptors
before starting a call on the given channel. - intercept(ClientInterceptor...) - Method in class io.grpc.ForwardingChannelBuilder
- intercept(ClientInterceptor...) - Method in class io.grpc.ForwardingChannelBuilder2
- intercept(ClientInterceptor...) - Method in class io.grpc.internal.ManagedChannelImplBuilder
- 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.ForwardingServerBuilder
- intercept(ServerInterceptor) - Method in class io.grpc.internal.ServerImplBuilder
- intercept(ServerInterceptor) - Method in class io.grpc.ServerBuilder
-
Adds a
ServerInterceptor
that is run for all services on the server. - intercept(ServerServiceDefinition, ServerInterceptor...) - Static method in class io.grpc.ServerInterceptors
-
Create a new
ServerServiceDefinition
whoseServerCallHandler
s will callinterceptors
before calling the pre-existingServerCallHandler
. - intercept(ServerServiceDefinition, List<? extends ServerInterceptor>) - Static method in class io.grpc.ServerInterceptors
-
Create a new
ServerServiceDefinition
whoseServerCallHandler
s will callinterceptors
before calling the pre-existingServerCallHandler
. - intercept(List<ClientInterceptor>) - Method in class io.grpc.ForwardingChannelBuilder
- intercept(List<ClientInterceptor>) - Method in class io.grpc.ForwardingChannelBuilder2
- intercept(List<ClientInterceptor>) - Method in class io.grpc.internal.ManagedChannelImplBuilder
- intercept(List<ClientInterceptor>) - Method in class io.grpc.ManagedChannelBuilder
-
Adds interceptors that will be called before the channel performs its real work.
- 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(MethodDescriptor<ReqT, RespT>, CallOptions, Channel) - Method in interface io.grpc.ClientInterceptor
- interceptCall(MethodDescriptor<ReqT, RespT>, CallOptions, Channel) - Method in class io.grpc.internal.ManagedChannelImplBuilder.InterceptorFactoryWrapper
- interceptCall(MethodDescriptor<ReqT, RespT>, CallOptions, Channel) - Method in class io.grpc.protobuf.services.BinaryLogProvider.BinaryLogShim
- interceptCall(MethodDescriptor<ReqT, RespT>, CallOptions, Channel) - Method in class io.grpc.stub.MetadataUtils.HeaderAttachingClientInterceptor
- interceptCall(MethodDescriptor<ReqT, RespT>, CallOptions, Channel) - Method in class io.grpc.stub.MetadataUtils.MetadataCapturingClientInterceptor
- 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.stub.MetadataUtils.MetadataAttachingServerInterceptor
- interceptCall(ServerCall<ReqT, RespT>, Metadata, ServerCallHandler<ReqT, RespT>) - Method in class io.grpc.util.TransmitStatusRuntimeExceptionInterceptor
- InterceptCallHandler(ServerInterceptor, ServerCallHandler<ReqT, RespT>) - Constructor for class io.grpc.ServerInterceptors.InterceptCallHandler
- interceptCallHandlerCreate(ServerInterceptor, ServerCallHandler<ReqT, RespT>) - Static method in class io.grpc.InternalServerInterceptors
- interceptForward(BindableService, ServerInterceptor...) - Static method in class io.grpc.ServerInterceptors
- interceptForward(BindableService, List<? extends ServerInterceptor>) - Static method in class io.grpc.ServerInterceptors
- interceptForward(Channel, ClientInterceptor...) - Static method in class io.grpc.ClientInterceptors
-
Create a new
Channel
that will callinterceptors
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 callinterceptors
before starting a call on the given channel. - interceptForward(ServerServiceDefinition, ServerInterceptor...) - Static method in class io.grpc.ServerInterceptors
-
Create a new
ServerServiceDefinition
whoseServerCallHandler
s will callinterceptors
before calling the pre-existingServerCallHandler
. - interceptForward(ServerServiceDefinition, List<? extends ServerInterceptor>) - Static method in class io.grpc.ServerInterceptors
-
Create a new
ServerServiceDefinition
whoseServerCallHandler
s will callinterceptors
before calling the pre-existingServerCallHandler
. - interceptor - Variable in class io.grpc.ClientInterceptors.InterceptorChannel
- interceptor - Variable in class io.grpc.InternalConfigSelector.Result.Builder
- interceptor - Variable in class io.grpc.InternalConfigSelector.Result
- interceptor - Variable in class io.grpc.ServerInterceptors.InterceptCallHandler
- interceptorChannel - Variable in class io.grpc.internal.ManagedChannelImpl
-
We delegate to this channel, so that we can have interceptors as necessary.
- InterceptorChannel(Channel, ClientInterceptor) - Constructor for class io.grpc.ClientInterceptors.InterceptorChannel
- InterceptorFactoryWrapper(ManagedChannelBuilder.InterceptorFactory) - Constructor for class io.grpc.internal.ManagedChannelImplBuilder.InterceptorFactoryWrapper
- interceptors - Variable in class io.grpc.internal.ManagedChannelImplBuilder
- interceptors - Variable in class io.grpc.internal.ServerImpl
- interceptors - Variable in class io.grpc.internal.ServerImplBuilder
- interceptWithTarget(ManagedChannelBuilder.InterceptorFactory) - Method in class io.grpc.ForwardingChannelBuilder2
- interceptWithTarget(ManagedChannelBuilder.InterceptorFactory) - Method in class io.grpc.internal.ManagedChannelImplBuilder
- interceptWithTarget(ManagedChannelBuilder.InterceptorFactory) - Method in class io.grpc.ManagedChannelBuilder
-
Internal-only: Adds a factory that will construct an interceptor based on the channel's target.
- interceptWithTarget(ManagedChannelBuilder<T>, InternalManagedChannelBuilder.InternalInterceptorFactory) - Static method in class io.grpc.InternalManagedChannelBuilder
- 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 - Enum constant in enum io.grpc.Status.Code
-
Internal errors.
- INTERNAL - Static variable in class io.grpc.Status
-
Internal errors.
- INTERNAL_ERROR - Enum constant in enum io.grpc.internal.GrpcUtil.Http2Error
- internal_static_grpc_binarylog_v1_Address_descriptor - Static variable in class io.grpc.binarylog.v1.BinaryLogProto
- internal_static_grpc_binarylog_v1_Address_fieldAccessorTable - Static variable in class io.grpc.binarylog.v1.BinaryLogProto
- internal_static_grpc_binarylog_v1_ClientHeader_descriptor - Static variable in class io.grpc.binarylog.v1.BinaryLogProto
- internal_static_grpc_binarylog_v1_ClientHeader_fieldAccessorTable - Static variable in class io.grpc.binarylog.v1.BinaryLogProto
- internal_static_grpc_binarylog_v1_GrpcLogEntry_descriptor - Static variable in class io.grpc.binarylog.v1.BinaryLogProto
- internal_static_grpc_binarylog_v1_GrpcLogEntry_fieldAccessorTable - Static variable in class io.grpc.binarylog.v1.BinaryLogProto
- internal_static_grpc_binarylog_v1_Message_descriptor - Static variable in class io.grpc.binarylog.v1.BinaryLogProto
- internal_static_grpc_binarylog_v1_Message_fieldAccessorTable - Static variable in class io.grpc.binarylog.v1.BinaryLogProto
- internal_static_grpc_binarylog_v1_Metadata_descriptor - Static variable in class io.grpc.binarylog.v1.BinaryLogProto
- internal_static_grpc_binarylog_v1_Metadata_fieldAccessorTable - Static variable in class io.grpc.binarylog.v1.BinaryLogProto
- internal_static_grpc_binarylog_v1_MetadataEntry_descriptor - Static variable in class io.grpc.binarylog.v1.BinaryLogProto
- internal_static_grpc_binarylog_v1_MetadataEntry_fieldAccessorTable - Static variable in class io.grpc.binarylog.v1.BinaryLogProto
- internal_static_grpc_binarylog_v1_ServerHeader_descriptor - Static variable in class io.grpc.binarylog.v1.BinaryLogProto
- internal_static_grpc_binarylog_v1_ServerHeader_fieldAccessorTable - Static variable in class io.grpc.binarylog.v1.BinaryLogProto
- internal_static_grpc_binarylog_v1_Trailer_descriptor - Static variable in class io.grpc.binarylog.v1.BinaryLogProto
- internal_static_grpc_binarylog_v1_Trailer_fieldAccessorTable - Static variable in class io.grpc.binarylog.v1.BinaryLogProto
- internal_static_grpc_channelz_v1_Address_descriptor - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_Address_fieldAccessorTable - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_Address_OtherAddress_descriptor - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_Address_OtherAddress_fieldAccessorTable - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_Address_TcpIpAddress_descriptor - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_Address_TcpIpAddress_fieldAccessorTable - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_Address_UdsAddress_descriptor - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_Address_UdsAddress_fieldAccessorTable - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_Channel_descriptor - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_Channel_fieldAccessorTable - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_ChannelConnectivityState_descriptor - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_ChannelConnectivityState_fieldAccessorTable - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_ChannelData_descriptor - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_ChannelData_fieldAccessorTable - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_ChannelRef_descriptor - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_ChannelRef_fieldAccessorTable - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_ChannelTrace_descriptor - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_ChannelTrace_fieldAccessorTable - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_ChannelTraceEvent_descriptor - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_ChannelTraceEvent_fieldAccessorTable - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_GetChannelRequest_descriptor - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_GetChannelRequest_fieldAccessorTable - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_GetChannelResponse_descriptor - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_GetChannelResponse_fieldAccessorTable - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_GetServerRequest_descriptor - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_GetServerRequest_fieldAccessorTable - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_GetServerResponse_descriptor - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_GetServerResponse_fieldAccessorTable - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_GetServerSocketsRequest_descriptor - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_GetServerSocketsRequest_fieldAccessorTable - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_GetServerSocketsResponse_descriptor - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_GetServerSocketsResponse_fieldAccessorTable - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_GetServersRequest_descriptor - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_GetServersRequest_fieldAccessorTable - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_GetServersResponse_descriptor - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_GetServersResponse_fieldAccessorTable - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_GetSocketRequest_descriptor - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_GetSocketRequest_fieldAccessorTable - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_GetSocketResponse_descriptor - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_GetSocketResponse_fieldAccessorTable - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_GetSubchannelRequest_descriptor - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_GetSubchannelRequest_fieldAccessorTable - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_GetSubchannelResponse_descriptor - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_GetSubchannelResponse_fieldAccessorTable - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_GetTopChannelsRequest_descriptor - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_GetTopChannelsRequest_fieldAccessorTable - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_GetTopChannelsResponse_descriptor - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_GetTopChannelsResponse_fieldAccessorTable - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_Security_descriptor - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_Security_fieldAccessorTable - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_Security_OtherSecurity_descriptor - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_Security_OtherSecurity_fieldAccessorTable - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_Security_Tls_descriptor - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_Security_Tls_fieldAccessorTable - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_Server_descriptor - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_Server_fieldAccessorTable - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_ServerData_descriptor - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_ServerData_fieldAccessorTable - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_ServerRef_descriptor - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_ServerRef_fieldAccessorTable - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_Socket_descriptor - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_Socket_fieldAccessorTable - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_SocketData_descriptor - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_SocketData_fieldAccessorTable - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_SocketOption_descriptor - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_SocketOption_fieldAccessorTable - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_SocketOptionLinger_descriptor - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_SocketOptionLinger_fieldAccessorTable - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_SocketOptionTcpInfo_descriptor - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_SocketOptionTcpInfo_fieldAccessorTable - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_SocketOptionTimeout_descriptor - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_SocketOptionTimeout_fieldAccessorTable - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_SocketRef_descriptor - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_SocketRef_fieldAccessorTable - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_Subchannel_descriptor - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_Subchannel_fieldAccessorTable - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_SubchannelRef_descriptor - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_channelz_v1_SubchannelRef_fieldAccessorTable - Static variable in class io.grpc.channelz.v1.ChannelzProto
- internal_static_grpc_health_v1_HealthCheckRequest_descriptor - Static variable in class io.grpc.health.v1.HealthProto
- internal_static_grpc_health_v1_HealthCheckRequest_fieldAccessorTable - Static variable in class io.grpc.health.v1.HealthProto
- internal_static_grpc_health_v1_HealthCheckResponse_descriptor - Static variable in class io.grpc.health.v1.HealthProto
- internal_static_grpc_health_v1_HealthCheckResponse_fieldAccessorTable - Static variable in class io.grpc.health.v1.HealthProto
- internal_static_grpc_lb_v1_ClientStats_descriptor - Static variable in class io.grpc.lb.v1.LoadBalancerProto
- internal_static_grpc_lb_v1_ClientStats_fieldAccessorTable - Static variable in class io.grpc.lb.v1.LoadBalancerProto
- internal_static_grpc_lb_v1_ClientStatsPerToken_descriptor - Static variable in class io.grpc.lb.v1.LoadBalancerProto
- internal_static_grpc_lb_v1_ClientStatsPerToken_fieldAccessorTable - Static variable in class io.grpc.lb.v1.LoadBalancerProto
- internal_static_grpc_lb_v1_FallbackResponse_descriptor - Static variable in class io.grpc.lb.v1.LoadBalancerProto
- internal_static_grpc_lb_v1_FallbackResponse_fieldAccessorTable - Static variable in class io.grpc.lb.v1.LoadBalancerProto
- internal_static_grpc_lb_v1_InitialLoadBalanceRequest_descriptor - Static variable in class io.grpc.lb.v1.LoadBalancerProto
- internal_static_grpc_lb_v1_InitialLoadBalanceRequest_fieldAccessorTable - Static variable in class io.grpc.lb.v1.LoadBalancerProto
- internal_static_grpc_lb_v1_InitialLoadBalanceResponse_descriptor - Static variable in class io.grpc.lb.v1.LoadBalancerProto
- internal_static_grpc_lb_v1_InitialLoadBalanceResponse_fieldAccessorTable - Static variable in class io.grpc.lb.v1.LoadBalancerProto
- internal_static_grpc_lb_v1_LoadBalanceRequest_descriptor - Static variable in class io.grpc.lb.v1.LoadBalancerProto
- internal_static_grpc_lb_v1_LoadBalanceRequest_fieldAccessorTable - Static variable in class io.grpc.lb.v1.LoadBalancerProto
- internal_static_grpc_lb_v1_LoadBalanceResponse_descriptor - Static variable in class io.grpc.lb.v1.LoadBalancerProto
- internal_static_grpc_lb_v1_LoadBalanceResponse_fieldAccessorTable - Static variable in class io.grpc.lb.v1.LoadBalancerProto
- internal_static_grpc_lb_v1_Server_descriptor - Static variable in class io.grpc.lb.v1.LoadBalancerProto
- internal_static_grpc_lb_v1_Server_fieldAccessorTable - Static variable in class io.grpc.lb.v1.LoadBalancerProto
- internal_static_grpc_lb_v1_ServerList_descriptor - Static variable in class io.grpc.lb.v1.LoadBalancerProto
- internal_static_grpc_lb_v1_ServerList_fieldAccessorTable - Static variable in class io.grpc.lb.v1.LoadBalancerProto
- internal_static_grpc_lookup_v1_GrpcKeyBuilder_ConstantKeysEntry_descriptor - Static variable in class io.grpc.lookup.v1.RlsConfigProto
- internal_static_grpc_lookup_v1_GrpcKeyBuilder_ConstantKeysEntry_fieldAccessorTable - Static variable in class io.grpc.lookup.v1.RlsConfigProto
- internal_static_grpc_lookup_v1_GrpcKeyBuilder_descriptor - Static variable in class io.grpc.lookup.v1.RlsConfigProto
- internal_static_grpc_lookup_v1_GrpcKeyBuilder_ExtraKeys_descriptor - Static variable in class io.grpc.lookup.v1.RlsConfigProto
- internal_static_grpc_lookup_v1_GrpcKeyBuilder_ExtraKeys_fieldAccessorTable - Static variable in class io.grpc.lookup.v1.RlsConfigProto
- internal_static_grpc_lookup_v1_GrpcKeyBuilder_fieldAccessorTable - Static variable in class io.grpc.lookup.v1.RlsConfigProto
- internal_static_grpc_lookup_v1_GrpcKeyBuilder_Name_descriptor - Static variable in class io.grpc.lookup.v1.RlsConfigProto
- internal_static_grpc_lookup_v1_GrpcKeyBuilder_Name_fieldAccessorTable - Static variable in class io.grpc.lookup.v1.RlsConfigProto
- internal_static_grpc_lookup_v1_HttpKeyBuilder_ConstantKeysEntry_descriptor - Static variable in class io.grpc.lookup.v1.RlsConfigProto
- internal_static_grpc_lookup_v1_HttpKeyBuilder_ConstantKeysEntry_fieldAccessorTable - Static variable in class io.grpc.lookup.v1.RlsConfigProto
- internal_static_grpc_lookup_v1_HttpKeyBuilder_descriptor - Static variable in class io.grpc.lookup.v1.RlsConfigProto
- internal_static_grpc_lookup_v1_HttpKeyBuilder_fieldAccessorTable - Static variable in class io.grpc.lookup.v1.RlsConfigProto
- internal_static_grpc_lookup_v1_NameMatcher_descriptor - Static variable in class io.grpc.lookup.v1.RlsConfigProto
- internal_static_grpc_lookup_v1_NameMatcher_fieldAccessorTable - Static variable in class io.grpc.lookup.v1.RlsConfigProto
- internal_static_grpc_lookup_v1_RouteLookupClusterSpecifier_descriptor - Static variable in class io.grpc.lookup.v1.RlsConfigProto
- internal_static_grpc_lookup_v1_RouteLookupClusterSpecifier_fieldAccessorTable - Static variable in class io.grpc.lookup.v1.RlsConfigProto
- internal_static_grpc_lookup_v1_RouteLookupConfig_descriptor - Static variable in class io.grpc.lookup.v1.RlsConfigProto
- internal_static_grpc_lookup_v1_RouteLookupConfig_fieldAccessorTable - Static variable in class io.grpc.lookup.v1.RlsConfigProto
- internal_static_grpc_lookup_v1_RouteLookupRequest_descriptor - Static variable in class io.grpc.lookup.v1.RlsProto
- internal_static_grpc_lookup_v1_RouteLookupRequest_fieldAccessorTable - Static variable in class io.grpc.lookup.v1.RlsProto
- internal_static_grpc_lookup_v1_RouteLookupRequest_KeyMapEntry_descriptor - Static variable in class io.grpc.lookup.v1.RlsProto
- internal_static_grpc_lookup_v1_RouteLookupRequest_KeyMapEntry_fieldAccessorTable - Static variable in class io.grpc.lookup.v1.RlsProto
- internal_static_grpc_lookup_v1_RouteLookupResponse_descriptor - Static variable in class io.grpc.lookup.v1.RlsProto
- internal_static_grpc_lookup_v1_RouteLookupResponse_fieldAccessorTable - Static variable in class io.grpc.lookup.v1.RlsProto
- internal_static_grpc_reflection_v1_ErrorResponse_descriptor - Static variable in class io.grpc.reflection.v1.ServerReflectionProto
- internal_static_grpc_reflection_v1_ErrorResponse_fieldAccessorTable - Static variable in class io.grpc.reflection.v1.ServerReflectionProto
- internal_static_grpc_reflection_v1_ExtensionNumberResponse_descriptor - Static variable in class io.grpc.reflection.v1.ServerReflectionProto
- internal_static_grpc_reflection_v1_ExtensionNumberResponse_fieldAccessorTable - Static variable in class io.grpc.reflection.v1.ServerReflectionProto
- internal_static_grpc_reflection_v1_ExtensionRequest_descriptor - Static variable in class io.grpc.reflection.v1.ServerReflectionProto
- internal_static_grpc_reflection_v1_ExtensionRequest_fieldAccessorTable - Static variable in class io.grpc.reflection.v1.ServerReflectionProto
- internal_static_grpc_reflection_v1_FileDescriptorResponse_descriptor - Static variable in class io.grpc.reflection.v1.ServerReflectionProto
- internal_static_grpc_reflection_v1_FileDescriptorResponse_fieldAccessorTable - Static variable in class io.grpc.reflection.v1.ServerReflectionProto
- internal_static_grpc_reflection_v1_ListServiceResponse_descriptor - Static variable in class io.grpc.reflection.v1.ServerReflectionProto
- internal_static_grpc_reflection_v1_ListServiceResponse_fieldAccessorTable - Static variable in class io.grpc.reflection.v1.ServerReflectionProto
- internal_static_grpc_reflection_v1_ServerReflectionRequest_descriptor - Static variable in class io.grpc.reflection.v1.ServerReflectionProto
- internal_static_grpc_reflection_v1_ServerReflectionRequest_fieldAccessorTable - Static variable in class io.grpc.reflection.v1.ServerReflectionProto
- internal_static_grpc_reflection_v1_ServerReflectionResponse_descriptor - Static variable in class io.grpc.reflection.v1.ServerReflectionProto
- internal_static_grpc_reflection_v1_ServerReflectionResponse_fieldAccessorTable - Static variable in class io.grpc.reflection.v1.ServerReflectionProto
- internal_static_grpc_reflection_v1_ServiceResponse_descriptor - Static variable in class io.grpc.reflection.v1.ServerReflectionProto
- internal_static_grpc_reflection_v1_ServiceResponse_fieldAccessorTable - Static variable in class io.grpc.reflection.v1.ServerReflectionProto
- internal_static_grpc_reflection_v1alpha_ErrorResponse_descriptor - Static variable in class io.grpc.reflection.v1alpha.ServerReflectionProto
-
Deprecated.
- internal_static_grpc_reflection_v1alpha_ErrorResponse_fieldAccessorTable - Static variable in class io.grpc.reflection.v1alpha.ServerReflectionProto
-
Deprecated.
- internal_static_grpc_reflection_v1alpha_ExtensionNumberResponse_descriptor - Static variable in class io.grpc.reflection.v1alpha.ServerReflectionProto
-
Deprecated.
- internal_static_grpc_reflection_v1alpha_ExtensionNumberResponse_fieldAccessorTable - Static variable in class io.grpc.reflection.v1alpha.ServerReflectionProto
-
Deprecated.
- internal_static_grpc_reflection_v1alpha_ExtensionRequest_descriptor - Static variable in class io.grpc.reflection.v1alpha.ServerReflectionProto
-
Deprecated.
- internal_static_grpc_reflection_v1alpha_ExtensionRequest_fieldAccessorTable - Static variable in class io.grpc.reflection.v1alpha.ServerReflectionProto
-
Deprecated.
- internal_static_grpc_reflection_v1alpha_FileDescriptorResponse_descriptor - Static variable in class io.grpc.reflection.v1alpha.ServerReflectionProto
-
Deprecated.
- internal_static_grpc_reflection_v1alpha_FileDescriptorResponse_fieldAccessorTable - Static variable in class io.grpc.reflection.v1alpha.ServerReflectionProto
-
Deprecated.
- internal_static_grpc_reflection_v1alpha_ListServiceResponse_descriptor - Static variable in class io.grpc.reflection.v1alpha.ServerReflectionProto
-
Deprecated.
- internal_static_grpc_reflection_v1alpha_ListServiceResponse_fieldAccessorTable - Static variable in class io.grpc.reflection.v1alpha.ServerReflectionProto
-
Deprecated.
- internal_static_grpc_reflection_v1alpha_ServerReflectionRequest_descriptor - Static variable in class io.grpc.reflection.v1alpha.ServerReflectionProto
-
Deprecated.
- internal_static_grpc_reflection_v1alpha_ServerReflectionRequest_fieldAccessorTable - Static variable in class io.grpc.reflection.v1alpha.ServerReflectionProto
-
Deprecated.
- internal_static_grpc_reflection_v1alpha_ServerReflectionResponse_descriptor - Static variable in class io.grpc.reflection.v1alpha.ServerReflectionProto
-
Deprecated.
- internal_static_grpc_reflection_v1alpha_ServerReflectionResponse_fieldAccessorTable - Static variable in class io.grpc.reflection.v1alpha.ServerReflectionProto
-
Deprecated.
- internal_static_grpc_reflection_v1alpha_ServiceResponse_descriptor - Static variable in class io.grpc.reflection.v1alpha.ServerReflectionProto
-
Deprecated.
- internal_static_grpc_reflection_v1alpha_ServiceResponse_fieldAccessorTable - Static variable in class io.grpc.reflection.v1alpha.ServerReflectionProto
-
Deprecated.
- internalCaller - Variable in class io.grpc.servlet.jakarta.ServletServerBuilder
- internalCaller - Variable in class io.grpc.servlet.ServletServerBuilder
- InternalCallMetricRecorder - Class in io.grpc.services
-
Internal
CallMetricRecorder
accessor. - InternalCallMetricRecorder() - Constructor for class io.grpc.services.InternalCallMetricRecorder
- InternalCallOptions - Class in io.grpc
-
Internal accessor for
CallOptions
. - InternalCallOptions() - Constructor for class io.grpc.InternalCallOptions
- internalCancel(Status) - Method in class io.grpc.inprocess.InProcessTransport.InProcessStream.InProcessServerStream
- internalCancel(Status, Status) - Method in class io.grpc.inprocess.InProcessTransport.InProcessStream.InProcessClientStream
- 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.ServerSocketMap - 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.
- InternalClientCalls - Class in io.grpc.stub
-
Internal
ClientCalls
accessor. - InternalClientCalls() - Constructor for class io.grpc.stub.InternalClientCalls
- InternalClientCalls.StubType - Enum in io.grpc.stub
-
Companion enum for internal enum
ClientCalls.StubType
. - InternalClientInterceptors - Class in io.grpc
-
Internal accessor.
- InternalClientInterceptors() - Constructor for class io.grpc.InternalClientInterceptors
- internalClose(Throwable) - Method in class io.grpc.internal.ServerImpl.JumpToApplicationThreadServerStreamListener
-
Like
ServerCall.close(Status, Metadata)
, but thread-safe for internal use. - InternalConfigSelector - Class in io.grpc
-
Per method config selector that the channel or load balancers will use to choose the appropriate config or take config related actions for an RPC.
- InternalConfigSelector() - Constructor for class io.grpc.InternalConfigSelector
- InternalConfigSelector.Result - Class in io.grpc
- InternalConfigSelector.Result.Builder - Class in io.grpc
- InternalConfigurator - Interface in io.grpc
-
Internal access to Configurator API.
- InternalConfiguratorRegistry - Class in io.grpc
-
Access internal global configurators.
- InternalConfiguratorRegistry() - Constructor for class io.grpc.InternalConfiguratorRegistry
- InternalDecompressorRegistry - Class in io.grpc
-
Private accessor for decompressor registries.
- InternalDecompressorRegistry() - Constructor for class io.grpc.InternalDecompressorRegistry
- internalGetConstantKeys() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
- internalGetConstantKeys() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder
- internalGetConstantKeys() - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
- internalGetConstantKeys() - Method in class io.grpc.lookup.v1.HttpKeyBuilder
- internalGetFieldAccessorTable() - Method in class io.grpc.binarylog.v1.Address.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.binarylog.v1.Address
- internalGetFieldAccessorTable() - Method in class io.grpc.binarylog.v1.ClientHeader.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.binarylog.v1.ClientHeader
- internalGetFieldAccessorTable() - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.binarylog.v1.GrpcLogEntry
- internalGetFieldAccessorTable() - Method in class io.grpc.binarylog.v1.Message.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.binarylog.v1.Message
- internalGetFieldAccessorTable() - Method in class io.grpc.binarylog.v1.Metadata.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.binarylog.v1.Metadata
- internalGetFieldAccessorTable() - Method in class io.grpc.binarylog.v1.MetadataEntry.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.binarylog.v1.MetadataEntry
- internalGetFieldAccessorTable() - Method in class io.grpc.binarylog.v1.ServerHeader.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.binarylog.v1.ServerHeader
- internalGetFieldAccessorTable() - Method in class io.grpc.binarylog.v1.Trailer.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.binarylog.v1.Trailer
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.Address.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.Address
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.Address.OtherAddress.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.Address.OtherAddress
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.Address.TcpIpAddress.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.Address.TcpIpAddress
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.Address.UdsAddress.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.Address.UdsAddress
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.Channel.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.Channel
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.ChannelConnectivityState.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.ChannelConnectivityState
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.ChannelData.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.ChannelData
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.ChannelRef.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.ChannelRef
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.ChannelTrace.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.ChannelTrace
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.ChannelTraceEvent.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.ChannelTraceEvent
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.GetChannelRequest.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.GetChannelRequest
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.GetChannelResponse.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.GetChannelResponse
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.GetServerRequest.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.GetServerRequest
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.GetServerResponse.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.GetServerResponse
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.GetServerSocketsRequest.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.GetServerSocketsRequest
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.GetServerSocketsResponse.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.GetServerSocketsResponse
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.GetServersRequest.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.GetServersRequest
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.GetServersResponse.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.GetServersResponse
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.GetSocketRequest.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.GetSocketRequest
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.GetSocketResponse.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.GetSocketResponse
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.GetSubchannelRequest.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.GetSubchannelRequest
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.GetSubchannelResponse.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.GetSubchannelResponse
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.GetTopChannelsRequest.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.GetTopChannelsRequest
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.GetTopChannelsResponse.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.GetTopChannelsResponse
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.Security.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.Security
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.Security.OtherSecurity.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.Security.OtherSecurity
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.Security.Tls.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.Security.Tls
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.Server.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.Server
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.ServerData.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.ServerData
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.ServerRef.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.ServerRef
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.Socket.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.Socket
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.SocketData.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.SocketData
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.SocketOption.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.SocketOption
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.SocketOptionLinger.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.SocketOptionLinger
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.SocketOptionTimeout.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.SocketOptionTimeout
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.SocketRef.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.SocketRef
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.Subchannel.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.Subchannel
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.SubchannelRef.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.channelz.v1.SubchannelRef
- internalGetFieldAccessorTable() - Method in class io.grpc.health.v1.HealthCheckRequest.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.health.v1.HealthCheckRequest
- internalGetFieldAccessorTable() - Method in class io.grpc.health.v1.HealthCheckResponse.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.health.v1.HealthCheckResponse
- internalGetFieldAccessorTable() - Method in class io.grpc.lb.v1.ClientStats.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.lb.v1.ClientStats
- internalGetFieldAccessorTable() - Method in class io.grpc.lb.v1.ClientStatsPerToken.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.lb.v1.ClientStatsPerToken
- internalGetFieldAccessorTable() - Method in class io.grpc.lb.v1.FallbackResponse.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.lb.v1.FallbackResponse
- internalGetFieldAccessorTable() - Method in class io.grpc.lb.v1.InitialLoadBalanceRequest.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.lb.v1.InitialLoadBalanceRequest
- internalGetFieldAccessorTable() - Method in class io.grpc.lb.v1.InitialLoadBalanceResponse.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.lb.v1.InitialLoadBalanceResponse
- internalGetFieldAccessorTable() - Method in class io.grpc.lb.v1.LoadBalanceRequest.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.lb.v1.LoadBalanceRequest
- internalGetFieldAccessorTable() - Method in class io.grpc.lb.v1.LoadBalanceResponse.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.lb.v1.LoadBalanceResponse
- internalGetFieldAccessorTable() - Method in class io.grpc.lb.v1.Server.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.lb.v1.Server
- internalGetFieldAccessorTable() - Method in class io.grpc.lb.v1.ServerList.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.lb.v1.ServerList
- internalGetFieldAccessorTable() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys
- internalGetFieldAccessorTable() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder
- internalGetFieldAccessorTable() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Name.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Name
- internalGetFieldAccessorTable() - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.lookup.v1.HttpKeyBuilder
- internalGetFieldAccessorTable() - Method in class io.grpc.lookup.v1.NameMatcher.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.lookup.v1.NameMatcher
- internalGetFieldAccessorTable() - Method in class io.grpc.lookup.v1.RouteLookupClusterSpecifier.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.lookup.v1.RouteLookupClusterSpecifier
- internalGetFieldAccessorTable() - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.lookup.v1.RouteLookupConfig
- internalGetFieldAccessorTable() - Method in class io.grpc.lookup.v1.RouteLookupRequest.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.lookup.v1.RouteLookupRequest
- internalGetFieldAccessorTable() - Method in class io.grpc.lookup.v1.RouteLookupResponse.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.lookup.v1.RouteLookupResponse
- internalGetFieldAccessorTable() - Method in class io.grpc.reflection.v1.ErrorResponse.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.reflection.v1.ErrorResponse
- internalGetFieldAccessorTable() - Method in class io.grpc.reflection.v1.ExtensionNumberResponse.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.reflection.v1.ExtensionNumberResponse
- internalGetFieldAccessorTable() - Method in class io.grpc.reflection.v1.ExtensionRequest.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.reflection.v1.ExtensionRequest
- internalGetFieldAccessorTable() - Method in class io.grpc.reflection.v1.FileDescriptorResponse.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.reflection.v1.FileDescriptorResponse
- internalGetFieldAccessorTable() - Method in class io.grpc.reflection.v1.ListServiceResponse.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.reflection.v1.ListServiceResponse
- internalGetFieldAccessorTable() - Method in class io.grpc.reflection.v1.ServerReflectionRequest.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.reflection.v1.ServerReflectionRequest
- internalGetFieldAccessorTable() - Method in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.reflection.v1.ServerReflectionResponse
- internalGetFieldAccessorTable() - Method in class io.grpc.reflection.v1.ServiceResponse.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.reflection.v1.ServiceResponse
- internalGetFieldAccessorTable() - Method in class io.grpc.reflection.v1alpha.ErrorResponse.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.reflection.v1alpha.ErrorResponse
- internalGetFieldAccessorTable() - Method in class io.grpc.reflection.v1alpha.ExtensionNumberResponse.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.reflection.v1alpha.ExtensionNumberResponse
- internalGetFieldAccessorTable() - Method in class io.grpc.reflection.v1alpha.ExtensionRequest.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.reflection.v1alpha.ExtensionRequest
- internalGetFieldAccessorTable() - Method in class io.grpc.reflection.v1alpha.FileDescriptorResponse.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.reflection.v1alpha.FileDescriptorResponse
- internalGetFieldAccessorTable() - Method in class io.grpc.reflection.v1alpha.ListServiceResponse.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.reflection.v1alpha.ListServiceResponse
- internalGetFieldAccessorTable() - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest
- internalGetFieldAccessorTable() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse
- internalGetFieldAccessorTable() - Method in class io.grpc.reflection.v1alpha.ServiceResponse.Builder
- internalGetFieldAccessorTable() - Method in class io.grpc.reflection.v1alpha.ServiceResponse
- internalGetKeyMap() - Method in class io.grpc.lookup.v1.RouteLookupRequest.Builder
- internalGetKeyMap() - Method in class io.grpc.lookup.v1.RouteLookupRequest
- internalGetMapFieldReflection(int) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
- internalGetMapFieldReflection(int) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder
- internalGetMapFieldReflection(int) - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
- internalGetMapFieldReflection(int) - Method in class io.grpc.lookup.v1.HttpKeyBuilder
- internalGetMapFieldReflection(int) - Method in class io.grpc.lookup.v1.RouteLookupRequest.Builder
- internalGetMapFieldReflection(int) - Method in class io.grpc.lookup.v1.RouteLookupRequest
- internalGetMutableConstantKeys() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
- internalGetMutableConstantKeys() - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
- internalGetMutableKeyMap() - Method in class io.grpc.lookup.v1.RouteLookupRequest.Builder
- internalGetMutableMapFieldReflection(int) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
- internalGetMutableMapFieldReflection(int) - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
- internalGetMutableMapFieldReflection(int) - Method in class io.grpc.lookup.v1.RouteLookupRequest.Builder
- internalGetValueMap() - Static method in enum io.grpc.binarylog.v1.Address.Type
- internalGetValueMap() - Static method in enum io.grpc.binarylog.v1.GrpcLogEntry.EventType
- internalGetValueMap() - Static method in enum io.grpc.binarylog.v1.GrpcLogEntry.Logger
- internalGetValueMap() - Static method in enum io.grpc.channelz.v1.ChannelConnectivityState.State
- internalGetValueMap() - Static method in enum io.grpc.channelz.v1.ChannelTraceEvent.Severity
- internalGetValueMap() - Static method in enum io.grpc.health.v1.HealthCheckResponse.ServingStatus
- internalGetValueMap() - Static method in enum io.grpc.lookup.v1.RouteLookupRequest.Reason
- InternalGracefulServerCloseCommand - Class in io.grpc.netty
-
Internal accessor for
GracefulServerCloseCommand
. - InternalGracefulServerCloseCommand() - Constructor for class io.grpc.netty.InternalGracefulServerCloseCommand
- InternalGrpclbConstantsAccessor - Class in io.grpc.grpclb
-
Internal
GrpclbConstants
accessor. - InternalGrpclbConstantsAccessor() - Constructor for class io.grpc.grpclb.InternalGrpclbConstantsAccessor
- InternalHandlerRegistry - Class in io.grpc.internal
- InternalHandlerRegistry(List<ServerServiceDefinition>, Map<String, ServerMethodDefinition<?, ?>>) - Constructor for class io.grpc.internal.InternalHandlerRegistry
- InternalHandlerRegistry.Builder - Class in io.grpc.internal
- InternalInProcessChannelBuilder - Class in io.grpc.inprocess
-
Internal
InProcessChannelBuilder
accessor. - InternalInProcessChannelBuilder() - Constructor for class io.grpc.inprocess.InternalInProcessChannelBuilder
- InternalInProcessServerBuilder - Class in io.grpc.inprocess
-
Internal
InProcessServerBuilder
accessor. - InternalInProcessServerBuilder() - Constructor for class io.grpc.inprocess.InternalInProcessServerBuilder
- InternalInstrumented<T> - Interface in io.grpc
-
An internal class.
- InternalKnownTransport - Enum in io.grpc
-
All known transports.
- InternalKnownTransport() - Constructor for enum io.grpc.InternalKnownTransport
- InternalLogId - Class in io.grpc
-
An internal class.
- InternalLogId(String, String, long) - Constructor for class io.grpc.InternalLogId
- InternalManagedChannelBuilder - Class in io.grpc
-
Internal accessors for
ManagedChannelBuilder
. - InternalManagedChannelBuilder() - Constructor for class io.grpc.InternalManagedChannelBuilder
- InternalManagedChannelBuilder.InternalInterceptorFactory - Interface in io.grpc
- InternalManagedChannelProvider - Class in io.grpc
-
Internal accessor for
ManagedChannelProvider
. - InternalManagedChannelProvider() - Constructor for class io.grpc.InternalManagedChannelProvider
- InternalMayRequireSpecificExecutor - Interface in io.grpc
- InternalMetadata - Class in io.grpc
-
Internal
Metadata
accessor. - 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
- InternalMetricRecorder - Class in io.grpc.services
-
Internal
CallMetricRecorder
accessor. - InternalMetricRecorder() - Constructor for class io.grpc.services.InternalMetricRecorder
- InternalNativeSocketOptions(InternalChannelz.TcpInfo, Map<String, String>) - Constructor for class io.grpc.netty.InternalNettySocketSupport.InternalNativeSocketOptions
- InternalNettyChannelBuilder - Class in io.grpc.netty
-
Internal
NettyChannelBuilder
accessor. - InternalNettyChannelBuilder() - Constructor for class io.grpc.netty.InternalNettyChannelBuilder
- InternalNettyChannelBuilder.ProtocolNegotiatorFactory - Interface in io.grpc.netty
-
A class that provides a Netty handler to control protocol negotiation.
- InternalNettyChannelCredentials - Class in io.grpc.netty
-
Internal
NettyChannelCredentials
accessor. - InternalNettyChannelCredentials() - Constructor for class io.grpc.netty.InternalNettyChannelCredentials
- InternalNettyServerBuilder - Class in io.grpc.netty
-
Internal
NettyServerBuilder
accessor. - InternalNettyServerBuilder() - Constructor for class io.grpc.netty.InternalNettyServerBuilder
- InternalNettyServerCredentials - Class in io.grpc.netty
-
Internal
NettyServerCredentials
accessor. - InternalNettyServerCredentials() - Constructor for class io.grpc.netty.InternalNettyServerCredentials
- InternalNettySocketSupport - Class in io.grpc.netty
-
An internal accessor.
- InternalNettySocketSupport() - Constructor for class io.grpc.netty.InternalNettySocketSupport
- InternalNettySocketSupport.InternalHelper - Interface in io.grpc.netty
- InternalNettySocketSupport.InternalNativeSocketOptions - Class in io.grpc.netty
- InternalProtocolNegotiationEvent - Class in io.grpc.netty
-
Internal accessor for
ProtocolNegotiationEvent
. - InternalProtocolNegotiationEvent() - Constructor for class io.grpc.netty.InternalProtocolNegotiationEvent
- InternalProtocolNegotiator - Class in io.grpc.netty
-
Internal accessor for
InternalProtocolNegotiator.ProtocolNegotiator
. - InternalProtocolNegotiator() - Constructor for class io.grpc.netty.InternalProtocolNegotiator
- InternalProtocolNegotiator.ClientFactory - Interface in io.grpc.netty
- InternalProtocolNegotiator.ProtocolNegotiator - Interface in io.grpc.netty
- InternalProtocolNegotiator.ProtocolNegotiatorAdapter - Class in io.grpc.netty
- InternalProtocolNegotiator.ServerFactory - Interface in io.grpc.netty
- InternalProtocolNegotiators - Class in io.grpc.netty
-
Internal accessor for
ProtocolNegotiators
. - InternalProtocolNegotiators() - Constructor for class io.grpc.netty.InternalProtocolNegotiators
- InternalProtocolNegotiators.ProtocolNegotiationHandler - Class in io.grpc.netty
- InternalResolutionResult() - Constructor for class io.grpc.internal.DnsNameResolver.InternalResolutionResult
- internalServer - Variable in class io.grpc.servlet.jakarta.ServletServerBuilder
- internalServer - Variable in class io.grpc.servlet.ServletServerBuilder
- InternalServer - Class in io.grpc
- InternalServer - Interface in io.grpc.internal
-
An object that accepts new incoming connections on one or more listening socket addresses.
- InternalServer() - Constructor for class io.grpc.InternalServer
- InternalServerImpl() - Constructor for class io.grpc.servlet.jakarta.ServletServerBuilder.InternalServerImpl
- InternalServerImpl() - Constructor for class io.grpc.servlet.ServletServerBuilder.InternalServerImpl
- InternalServerInterceptors - Class in io.grpc
-
Accessor to internal methods of
ServerInterceptors
. - InternalServerInterceptors() - Constructor for class io.grpc.InternalServerInterceptors
- InternalServerProvider - Class in io.grpc
-
Internal accessor for
ServerProvider
. - InternalServerProvider() - Constructor for class io.grpc.InternalServerProvider
- InternalServiceProviders - Class in io.grpc
- InternalServiceProviders() - Constructor for class io.grpc.InternalServiceProviders
- InternalServiceProviders.PriorityAccessor<T> - Interface in io.grpc
- internalStart(ClientStreamListener) - Method in class io.grpc.internal.DelayedStream
-
Starts stream without synchronization.
- InternalStatus - Class in io.grpc
-
Accesses internal data.
- InternalStatus() - Constructor for class io.grpc.InternalStatus
- InternalSubchannel - Class in io.grpc.internal
-
Transports for a single
SocketAddress
. - InternalSubchannel(LoadBalancer.CreateSubchannelArgs, String, String, BackoffPolicy.Provider, ClientTransportFactory, ScheduledExecutorService, Supplier<Stopwatch>, SynchronizationContext, InternalSubchannel.Callback, InternalChannelz, CallTracer, ChannelTracer, InternalLogId, ChannelLogger, List<ClientTransportFilter>) - Constructor for class io.grpc.internal.InternalSubchannel
- InternalSubchannel.Callback - Class in io.grpc.internal
- InternalSubchannel.CallTracingTransport - Class in io.grpc.internal
- InternalSubchannel.Index - Class in io.grpc.internal
-
Index as in 'i', the pointer to an entry.
- InternalSubchannel.TransportListener - Class in io.grpc.internal
-
Listener for real transports.
- InternalSubchannel.TransportLogger - Class in io.grpc.internal
- InternalSubchannelAddressAttributes - Interface in io.grpc
-
An internal class.
- internalType - Variable in enum io.grpc.stub.InternalClientCalls.StubType
- internalValueMap - Static variable in enum io.grpc.binarylog.v1.Address.Type
- internalValueMap - Static variable in enum io.grpc.binarylog.v1.GrpcLogEntry.EventType
- internalValueMap - Static variable in enum io.grpc.binarylog.v1.GrpcLogEntry.Logger
- internalValueMap - Static variable in enum io.grpc.channelz.v1.ChannelConnectivityState.State
- internalValueMap - Static variable in enum io.grpc.channelz.v1.ChannelTraceEvent.Severity
- internalValueMap - Static variable in enum io.grpc.health.v1.HealthCheckResponse.ServingStatus
- internalValueMap - Static variable in enum io.grpc.lookup.v1.RouteLookupRequest.Reason
- InternalWithLogId - Interface in io.grpc
-
An internal class.
- InternalWriteBufferingAndExceptionHandlerUtils - Class in io.grpc.netty
-
Utility class for
WriteBufferingAndExceptionHandler
. - InternalWriteBufferingAndExceptionHandlerUtils() - Constructor for class io.grpc.netty.InternalWriteBufferingAndExceptionHandlerUtils
- interruptTask() - Method in class io.grpc.stub.ClientCalls.GrpcFuture
- interval - Variable in class io.grpc.rls.AdaptiveThrottler.TimeBasedAccumulator
-
The time interval this statistic is concerned with.
- intervalNanos - Variable in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig.Builder
- intervalNanos - Variable in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig
- inUseObjects - Variable in class io.grpc.internal.InUseStateAggregator
- inUseState - Variable in class io.grpc.inprocess.InProcessTransport
- inUseState - Variable in class io.grpc.netty.NettyClientHandler
- inUseStateAggregator - Variable in class io.grpc.internal.InternalSubchannel
- inUseStateAggregator - Variable in class io.grpc.internal.ManagedChannelImpl
- InUseStateAggregator<T> - Class in io.grpc.internal
-
Aggregates the in-use state of a set of objects.
- InUseStateAggregator() - Constructor for class io.grpc.internal.InUseStateAggregator
- INVALID_ARGUMENT - Enum constant in enum io.grpc.Status.Code
-
Client specified an invalid argument.
- INVALID_ARGUMENT - Static variable in class io.grpc.Status
-
Client specified an invalid argument.
- invalidate(K) - Method in class io.grpc.rls.LinkedHashLruCache
- invalidate(K) - Method in interface io.grpc.rls.LruCache
-
Invalidates an entry for given key if exists.
- invalidate(K, LruCache.EvictionType) - Method in class io.grpc.rls.LinkedHashLruCache
- invalidateAll() - Method in class io.grpc.rls.LinkedHashLruCache
- invalidateAll() - Method in interface io.grpc.rls.LruCache
-
Invalidates cache entries for all keys.
- InvalidChildPolicyConfigException(String) - Constructor for exception class io.grpc.rls.LbPolicyConfiguration.InvalidChildPolicyConfigException
- invoke(StreamObserver<Resp>) - Method in class io.grpc.channelz.v1.ChannelzGrpc.MethodHandlers
- invoke(StreamObserver<Resp>) - Method in class io.grpc.health.v1.HealthGrpc.MethodHandlers
- invoke(StreamObserver<Resp>) - Method in class io.grpc.lb.v1.LoadBalancerGrpc.MethodHandlers
- invoke(StreamObserver<Resp>) - Method in class io.grpc.lookup.v1.RouteLookupServiceGrpc.MethodHandlers
- invoke(StreamObserver<Resp>) - Method in class io.grpc.reflection.v1.ServerReflectionGrpc.MethodHandlers
- invoke(StreamObserver<Resp>) - Method in class io.grpc.reflection.v1alpha.ServerReflectionGrpc.MethodHandlers
- invoke(StreamObserver<RespT>) - Method in interface io.grpc.stub.ServerCalls.BidiStreamingMethod
- invoke(StreamObserver<RespT>) - Method in interface io.grpc.stub.ServerCalls.ClientStreamingMethod
- invoke(StreamObserver<RespT>) - Method in interface io.grpc.stub.ServerCalls.StreamingRequestMethod
-
The provided
responseObserver
will extendServerCallStreamObserver
. - invoke(Req, StreamObserver<Resp>) - Method in class io.grpc.channelz.v1.ChannelzGrpc.MethodHandlers
- invoke(Req, StreamObserver<Resp>) - Method in class io.grpc.health.v1.HealthGrpc.MethodHandlers
- invoke(Req, StreamObserver<Resp>) - Method in class io.grpc.lb.v1.LoadBalancerGrpc.MethodHandlers
- invoke(Req, StreamObserver<Resp>) - Method in class io.grpc.lookup.v1.RouteLookupServiceGrpc.MethodHandlers
- invoke(Req, StreamObserver<Resp>) - Method in class io.grpc.reflection.v1.ServerReflectionGrpc.MethodHandlers
- invoke(Req, StreamObserver<Resp>) - Method in class io.grpc.reflection.v1alpha.ServerReflectionGrpc.MethodHandlers
- invoke(ReqT, StreamObserver<RespT>) - Method in interface io.grpc.stub.ServerCalls.ServerStreamingMethod
- invoke(ReqT, StreamObserver<RespT>) - Method in interface io.grpc.stub.ServerCalls.UnaryMethod
- invoke(ReqT, StreamObserver<RespT>) - Method in interface io.grpc.stub.ServerCalls.UnaryRequestMethod
-
The provided
responseObserver
will extendServerCallStreamObserver
. - invokeAll(Collection<? extends Callable<T>>) - Method in class io.grpc.internal.ManagedChannelImpl.RestrictedScheduledExecutor
- invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class io.grpc.internal.ManagedChannelImpl.RestrictedScheduledExecutor
- invokeAny(Collection<? extends Callable<T>>) - Method in class io.grpc.internal.ManagedChannelImpl.RestrictedScheduledExecutor
- invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class io.grpc.internal.ManagedChannelImpl.RestrictedScheduledExecutor
- io.grpc - package io.grpc
-
The gRPC core public API.
- io.grpc.binarylog.v1 - package io.grpc.binarylog.v1
- io.grpc.channelz.v1 - package io.grpc.channelz.v1
- io.grpc.grpclb - package io.grpc.grpclb
- io.grpc.health.v1 - package io.grpc.health.v1
- 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.lb.v1 - package io.grpc.lb.v1
- io.grpc.lookup.v1 - package io.grpc.lookup.v1
- io.grpc.netty - package io.grpc.netty
-
The main transport implementation based on Netty, for both the client and the server.
- io.grpc.protobuf - package io.grpc.protobuf
-
API for gRPC over Protocol Buffers, including tools for serializing and de-serializing protobuf messages.
- io.grpc.protobuf.lite - package io.grpc.protobuf.lite
-
API for gRPC over Protocol Buffers with proto message classes generated by the Lite Runtime library.
- io.grpc.protobuf.services - package io.grpc.protobuf.services
-
Service definitions and utilities with protobuf dependency for the pre-defined gRPC services.
- io.grpc.protobuf.services.internal - package io.grpc.protobuf.services.internal
- io.grpc.reflection.v1 - package io.grpc.reflection.v1
- io.grpc.reflection.v1alpha - package io.grpc.reflection.v1alpha
- io.grpc.rls - package io.grpc.rls
- io.grpc.services - package io.grpc.services
-
Service definitions and utilities for the pre-defined gRPC services.
- io.grpc.servlet - package io.grpc.servlet
-
API that implements gRPC server as a servlet.
- io.grpc.servlet.jakarta - package io.grpc.servlet.jakarta
-
API that implements gRPC server as a servlet.
- io.grpc.stub - package io.grpc.stub
-
API for the Stub layer.
- io.grpc.stub.annotations - package io.grpc.stub.annotations
- io.grpc.util - package io.grpc.util
-
Utilities with advanced features in the core layer that user can optionally use.
- IoUtils() - Constructor for class io.grpc.protobuf.services.BinaryLogProvider.IoUtils
- IP_ADDRESS_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.Address.TcpIpAddress
- IP_ADDRESS_FIELD_NUMBER - Static variable in class io.grpc.lb.v1.Server
- IP_PORT_FIELD_NUMBER - Static variable in class io.grpc.binarylog.v1.Address
- ipAddress_ - Variable in class io.grpc.channelz.v1.Address.TcpIpAddress.Builder
- ipAddress_ - Variable in class io.grpc.channelz.v1.Address.TcpIpAddress
- ipAddress_ - Variable in class io.grpc.lb.v1.Server.Builder
- ipAddress_ - Variable in class io.grpc.lb.v1.Server
- ipPort_ - Variable in class io.grpc.binarylog.v1.Address.Builder
- ipPort_ - Variable in class io.grpc.binarylog.v1.Address
- IPV6_PART_COUNT - Static variable in class io.grpc.protobuf.services.InetAddressUtil
- IS_ANDROID - Static variable in class io.grpc.grpclb.SecretGrpclbNameResolverProvider.Provider
- IS_ANDROID - Static variable in class io.grpc.internal.DnsNameResolverProvider
- IS_CONSCRYPT_METHOD - Static variable in class io.grpc.internal.ConscryptLoader
- IS_PETIOLE_POLICY - Static variable in class io.grpc.LoadBalancer
- isAbeforeB(Deadline, Deadline) - Method in class io.grpc.internal.DelayedClientCall
- isAboveThreshold() - Method in class io.grpc.internal.RetriableStream.Throttle
- isActive - Variable in class io.grpc.internal.MaxConnectionIdleManager
- isAndroid(ClassLoader) - Static method in class io.grpc.InternalServiceProviders
-
Accessor for
ServiceProviders.isAndroid(java.lang.ClassLoader)
. - isAndroid(ClassLoader) - Static method in class io.grpc.ServiceProviders
-
Returns true if the
ClassLoader
is for android. - isAtBeginning() - Method in class io.grpc.internal.InternalSubchannel.Index
- isAtBeginning() - Method in class io.grpc.internal.PickFirstLeafLoadBalancer.Index
- isAvailable() - Method in class io.grpc.grpclb.GrpclbLoadBalancerProvider
- isAvailable() - Method in class io.grpc.grpclb.SecretGrpclbNameResolverProvider.Provider
- isAvailable() - Method in class io.grpc.internal.DnsNameResolverProvider
- isAvailable() - Method in class io.grpc.internal.ManagedChannelImplBuilder.DirectAddressNameResolverProvider
- isAvailable() - Method in class io.grpc.internal.NameResolverFactoryToProviderFacade
- isAvailable() - Method in class io.grpc.internal.PickFirstLoadBalancerProvider
- isAvailable() - Static method in class io.grpc.internal.ReflectionLongAdderCounter
-
Returns true if the environment supports LongAdder.
- isAvailable() - Method in class io.grpc.LoadBalancerProvider
-
Whether this provider is available for use, taking the current environment into consideration.
- 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.netty.NettyChannelProvider
- isAvailable() - Method in class io.grpc.netty.NettyServerProvider
- isAvailable() - Method in class io.grpc.netty.UdsNameResolverProvider
- isAvailable() - Method in class io.grpc.netty.UdsNettyChannelProvider
- isAvailable() - Method in class io.grpc.protobuf.services.internal.HealthCheckingRoundRobinLoadBalancerProvider
- isAvailable() - Method in class io.grpc.rls.RlsLoadBalancerProvider
- isAvailable() - Method in class io.grpc.ServerProvider
-
Whether this provider is available for use, taking the current environment into consideration.
- isAvailable() - Method in class io.grpc.util.OutlierDetectionLoadBalancerProvider
- isAvailable() - Method in class io.grpc.util.SecretRoundRobinLoadBalancerProvider.Provider
- isAvailable(LoadBalancerProvider) - Method in class io.grpc.LoadBalancerRegistry.LoadBalancerPriorityAccessor
- isAvailable(ManagedChannelProvider) - Static method in class io.grpc.InternalManagedChannelProvider
- isAvailable(ManagedChannelProvider) - Method in class io.grpc.ManagedChannelRegistry.ManagedChannelPriorityAccessor
- isAvailable(NameResolverProvider) - Method in class io.grpc.NameResolverRegistry.NameResolverPriorityAccessor
- isAvailable(ServerProvider) - Method in class io.grpc.ServerRegistry.ServerPriorityAccessor
- isAvailable(T) - Method in interface io.grpc.ServiceProviders.PriorityAccessor
-
Checks this provider is available for use, taking the current environment into consideration.
- isBefore(Deadline) - Method in class io.grpc.Deadline
-
Is
this
deadline before another. - isCancelled - Variable in class io.grpc.SynchronizationContext.ManagedRunnable
- 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.internal.RetriableStream.FutureCanceller
- isCancelled() - Method in class io.grpc.internal.ServerCallImpl
- isCancelled() - Method in class io.grpc.PartialForwardingServerCall
- 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. - isCancelled() - Method in class io.grpc.ServerStreamTracer.ReadOnlyServerCall
-
Deprecated.
- isCancelled() - Method in class io.grpc.stub.ServerCalls.ServerCallStreamObserverImpl
- isCancelled() - Method in class io.grpc.stub.ServerCallStreamObserver
-
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. - isCancelled() - Method in class io.grpc.util.TransmitStatusRuntimeExceptionInterceptor.SerializingServerCall
- isClosed - Variable in class io.grpc.internal.RetriableStream
- isClosed() - Method in class io.grpc.internal.AbstractClientStream.GetFramer
- isClosed() - Method in interface io.grpc.internal.Framer
-
Returns whether the framer is closed.
- isClosed() - Method in class io.grpc.internal.MessageDeframer
-
Indicates whether or not this deframer has been closed.
- isClosed() - Method in class io.grpc.internal.MessageFramer
-
Indicates whether or not this framer has been closed via a call to either
MessageFramer.close()
orMessageFramer.dispose()
. - isClosedOrScheduledToClose() - Method in class io.grpc.internal.MessageDeframer
-
Returns true if this deframer has already been closed or scheduled to close.
- isCompletedConnectivityAttempt() - Method in class io.grpc.internal.PickFirstLeafLoadBalancer.SubchannelData
- isConscrypt(Provider) - Static method in class io.grpc.internal.ConscryptLoader
-
Same as
Conscrypt.isConscrypt(Provider)
. - isCpuOrApplicationUtilizationValid(double) - Static method in class io.grpc.services.MetricRecorderHelper
-
Return true if the cpu utilization or application specific utilization value is in the range [0, inf) and false otherwise.
- isCurrent() - Method in class io.grpc.Context.CancellableContext
-
Deprecated.This method violates some GRPC class encapsulation and should not be used. If you must know whether a Context is the current context, check whether it is the same object returned by
Context.current()
. - isCurrent() - Method in class io.grpc.Context
- isDisabled() - Method in class io.grpc.services.CallMetricRecorder
- isDrop() - Method in class io.grpc.LoadBalancer.PickResult
-
Returns
true
if this result was created bywithDrop()
. - isEjected() - Method in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionSubchannel
- isEmpty() - Method in class io.grpc.Metadata
-
checks when
Metadata.namesAndValues
is null or has no elements. - isEmpty() - Method in class io.grpc.netty.AbstractHttp2Headers
- isEnableByDefault() - Method in interface io.grpc.MetricInstrument
-
Indicates whether this metric instrument is enabled by default.
- isEnableByDefault() - Method in class io.grpc.PartialMetricInstrument
- isEnabled() - Method in class io.grpc.internal.Rescheduler.FutureRunnable
- isEnabled(Runnable) - Static method in class io.grpc.internal.Rescheduler
- isEnabledHappyEyeballs() - Static method in class io.grpc.internal.PickFirstLoadBalancerProvider
- isEnabledNewPickFirst() - Static method in class io.grpc.internal.PickFirstLoadBalancerProvider
- isEnabledSupportTracingMessageSizes - Static variable in class io.grpc.inprocess.InProcessTransport
- isEpollAvailable() - Static method in class io.grpc.netty.Utils
- isEscapingChar(byte) - Static method in class io.grpc.Status.StatusMessageMarshaller
- isExpired() - Method in class io.grpc.Deadline
-
Returns whether this has deadline expired.
- isExpired(long) - Method in class io.grpc.rls.CachingRlsLbClient.BackoffCacheEntry
- isExpired(long) - Method in class io.grpc.rls.CachingRlsLbClient.CacheEntry
- isExpired(long) - Method in class io.grpc.rls.CachingRlsLbClient.DataCacheEntry
- isExpired(RlsProtoData.RouteLookupRequest, CachingRlsLbClient.CacheEntry, long) - Method in class io.grpc.rls.CachingRlsLbClient.RlsAsyncLruCache
- isExpired(K, V, long) - Method in class io.grpc.rls.LinkedHashLruCache
-
Determines if the entry is already expired or not.
- isGet() - Method in class io.grpc.netty.CreateStreamCommand
- isGracefulShutdownComplete() - Method in class io.grpc.netty.NettyClientHandler
- isGrpc(HttpServletRequest) - Static method in class io.grpc.servlet.jakarta.ServletAdapter
-
Checks whether an incoming
HttpServletRequest
may come from a gRPC client. - isGrpc(HttpServletRequest) - Static method in class io.grpc.servlet.ServletAdapter
-
Checks whether an incoming
HttpServletRequest
may come from a gRPC client. - isGrpcContentType(String) - Static method in class io.grpc.internal.GrpcUtil
-
Indicates whether or not the given value is a valid gRPC content-type.
- isHedgeable - Variable in class io.grpc.internal.RetriableStream.HedgingPlan
- isHedging - Variable in class io.grpc.internal.RetriableStream
- isIdempotent() - Method in class io.grpc.MethodDescriptor
-
Returns whether this method is idempotent.
- isIndexValid() - Method in class io.grpc.internal.PickFirstLeafLoadBalancer
- isInitialized() - Method in class io.grpc.binarylog.v1.Address.Builder
- isInitialized() - Method in class io.grpc.binarylog.v1.Address
- isInitialized() - Method in class io.grpc.binarylog.v1.ClientHeader.Builder
- isInitialized() - Method in class io.grpc.binarylog.v1.ClientHeader
- isInitialized() - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
- isInitialized() - Method in class io.grpc.binarylog.v1.GrpcLogEntry
- isInitialized() - Method in class io.grpc.binarylog.v1.Message.Builder
- isInitialized() - Method in class io.grpc.binarylog.v1.Message
- isInitialized() - Method in class io.grpc.binarylog.v1.Metadata.Builder
- isInitialized() - Method in class io.grpc.binarylog.v1.Metadata
- isInitialized() - Method in class io.grpc.binarylog.v1.MetadataEntry.Builder
- isInitialized() - Method in class io.grpc.binarylog.v1.MetadataEntry
- isInitialized() - Method in class io.grpc.binarylog.v1.ServerHeader.Builder
- isInitialized() - Method in class io.grpc.binarylog.v1.ServerHeader
- isInitialized() - Method in class io.grpc.binarylog.v1.Trailer.Builder
- isInitialized() - Method in class io.grpc.binarylog.v1.Trailer
- isInitialized() - Method in class io.grpc.channelz.v1.Address.Builder
- isInitialized() - Method in class io.grpc.channelz.v1.Address
- isInitialized() - Method in class io.grpc.channelz.v1.Address.OtherAddress.Builder
- isInitialized() - Method in class io.grpc.channelz.v1.Address.OtherAddress
- isInitialized() - Method in class io.grpc.channelz.v1.Address.TcpIpAddress.Builder
- isInitialized() - Method in class io.grpc.channelz.v1.Address.TcpIpAddress
- isInitialized() - Method in class io.grpc.channelz.v1.Address.UdsAddress.Builder
- isInitialized() - Method in class io.grpc.channelz.v1.Address.UdsAddress
- isInitialized() - Method in class io.grpc.channelz.v1.Channel.Builder
- isInitialized() - Method in class io.grpc.channelz.v1.Channel
- isInitialized() - Method in class io.grpc.channelz.v1.ChannelConnectivityState.Builder
- isInitialized() - Method in class io.grpc.channelz.v1.ChannelConnectivityState
- isInitialized() - Method in class io.grpc.channelz.v1.ChannelData.Builder
- isInitialized() - Method in class io.grpc.channelz.v1.ChannelData
- isInitialized() - Method in class io.grpc.channelz.v1.ChannelRef.Builder
- isInitialized() - Method in class io.grpc.channelz.v1.ChannelRef
- isInitialized() - Method in class io.grpc.channelz.v1.ChannelTrace.Builder
- isInitialized() - Method in class io.grpc.channelz.v1.ChannelTrace
- isInitialized() - Method in class io.grpc.channelz.v1.ChannelTraceEvent.Builder
- isInitialized() - Method in class io.grpc.channelz.v1.ChannelTraceEvent
- isInitialized() - Method in class io.grpc.channelz.v1.GetChannelRequest.Builder
- isInitialized() - Method in class io.grpc.channelz.v1.GetChannelRequest
- isInitialized() - Method in class io.grpc.channelz.v1.GetChannelResponse.Builder
- isInitialized() - Method in class io.grpc.channelz.v1.GetChannelResponse
- isInitialized() - Method in class io.grpc.channelz.v1.GetServerRequest.Builder
- isInitialized() - Method in class io.grpc.channelz.v1.GetServerRequest
- isInitialized() - Method in class io.grpc.channelz.v1.GetServerResponse.Builder
- isInitialized() - Method in class io.grpc.channelz.v1.GetServerResponse
- isInitialized() - Method in class io.grpc.channelz.v1.GetServerSocketsRequest.Builder
- isInitialized() - Method in class io.grpc.channelz.v1.GetServerSocketsRequest
- isInitialized() - Method in class io.grpc.channelz.v1.GetServerSocketsResponse.Builder
- isInitialized() - Method in class io.grpc.channelz.v1.GetServerSocketsResponse
- isInitialized() - Method in class io.grpc.channelz.v1.GetServersRequest.Builder
- isInitialized() - Method in class io.grpc.channelz.v1.GetServersRequest
- isInitialized() - Method in class io.grpc.channelz.v1.GetServersResponse.Builder
- isInitialized() - Method in class io.grpc.channelz.v1.GetServersResponse
- isInitialized() - Method in class io.grpc.channelz.v1.GetSocketRequest.Builder
- isInitialized() - Method in class io.grpc.channelz.v1.GetSocketRequest
- isInitialized() - Method in class io.grpc.channelz.v1.GetSocketResponse.Builder
- isInitialized() - Method in class io.grpc.channelz.v1.GetSocketResponse
- isInitialized() - Method in class io.grpc.channelz.v1.GetSubchannelRequest.Builder
- isInitialized() - Method in class io.grpc.channelz.v1.GetSubchannelRequest
- isInitialized() - Method in class io.grpc.channelz.v1.GetSubchannelResponse.Builder
- isInitialized() - Method in class io.grpc.channelz.v1.GetSubchannelResponse
- isInitialized() - Method in class io.grpc.channelz.v1.GetTopChannelsRequest.Builder
- isInitialized() - Method in class io.grpc.channelz.v1.GetTopChannelsRequest
- isInitialized() - Method in class io.grpc.channelz.v1.GetTopChannelsResponse.Builder
- isInitialized() - Method in class io.grpc.channelz.v1.GetTopChannelsResponse
- isInitialized() - Method in class io.grpc.channelz.v1.Security.Builder
- isInitialized() - Method in class io.grpc.channelz.v1.Security
- isInitialized() - Method in class io.grpc.channelz.v1.Security.OtherSecurity.Builder
- isInitialized() - Method in class io.grpc.channelz.v1.Security.OtherSecurity
- isInitialized() - Method in class io.grpc.channelz.v1.Security.Tls.Builder
- isInitialized() - Method in class io.grpc.channelz.v1.Security.Tls
- isInitialized() - Method in class io.grpc.channelz.v1.Server.Builder
- isInitialized() - Method in class io.grpc.channelz.v1.Server
- isInitialized() - Method in class io.grpc.channelz.v1.ServerData.Builder
- isInitialized() - Method in class io.grpc.channelz.v1.ServerData
- isInitialized() - Method in class io.grpc.channelz.v1.ServerRef.Builder
- isInitialized() - Method in class io.grpc.channelz.v1.ServerRef
- isInitialized() - Method in class io.grpc.channelz.v1.Socket.Builder
- isInitialized() - Method in class io.grpc.channelz.v1.Socket
- isInitialized() - Method in class io.grpc.channelz.v1.SocketData.Builder
- isInitialized() - Method in class io.grpc.channelz.v1.SocketData
- isInitialized() - Method in class io.grpc.channelz.v1.SocketOption.Builder
- isInitialized() - Method in class io.grpc.channelz.v1.SocketOption
- isInitialized() - Method in class io.grpc.channelz.v1.SocketOptionLinger.Builder
- isInitialized() - Method in class io.grpc.channelz.v1.SocketOptionLinger
- isInitialized() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
- isInitialized() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo
- isInitialized() - Method in class io.grpc.channelz.v1.SocketOptionTimeout.Builder
- isInitialized() - Method in class io.grpc.channelz.v1.SocketOptionTimeout
- isInitialized() - Method in class io.grpc.channelz.v1.SocketRef.Builder
- isInitialized() - Method in class io.grpc.channelz.v1.SocketRef
- isInitialized() - Method in class io.grpc.channelz.v1.Subchannel.Builder
- isInitialized() - Method in class io.grpc.channelz.v1.Subchannel
- isInitialized() - Method in class io.grpc.channelz.v1.SubchannelRef.Builder
- isInitialized() - Method in class io.grpc.channelz.v1.SubchannelRef
- isInitialized() - Method in class io.grpc.health.v1.HealthCheckRequest.Builder
- isInitialized() - Method in class io.grpc.health.v1.HealthCheckRequest
- isInitialized() - Method in class io.grpc.health.v1.HealthCheckResponse.Builder
- isInitialized() - Method in class io.grpc.health.v1.HealthCheckResponse
- isInitialized() - Method in class io.grpc.lb.v1.ClientStats.Builder
- isInitialized() - Method in class io.grpc.lb.v1.ClientStats
- isInitialized() - Method in class io.grpc.lb.v1.ClientStatsPerToken.Builder
- isInitialized() - Method in class io.grpc.lb.v1.ClientStatsPerToken
- isInitialized() - Method in class io.grpc.lb.v1.FallbackResponse.Builder
- isInitialized() - Method in class io.grpc.lb.v1.FallbackResponse
- isInitialized() - Method in class io.grpc.lb.v1.InitialLoadBalanceRequest.Builder
- isInitialized() - Method in class io.grpc.lb.v1.InitialLoadBalanceRequest
- isInitialized() - Method in class io.grpc.lb.v1.InitialLoadBalanceResponse.Builder
- isInitialized() - Method in class io.grpc.lb.v1.InitialLoadBalanceResponse
- isInitialized() - Method in class io.grpc.lb.v1.LoadBalanceRequest.Builder
- isInitialized() - Method in class io.grpc.lb.v1.LoadBalanceRequest
- isInitialized() - Method in class io.grpc.lb.v1.LoadBalanceResponse.Builder
- isInitialized() - Method in class io.grpc.lb.v1.LoadBalanceResponse
- isInitialized() - Method in class io.grpc.lb.v1.Server.Builder
- isInitialized() - Method in class io.grpc.lb.v1.Server
- isInitialized() - Method in class io.grpc.lb.v1.ServerList.Builder
- isInitialized() - Method in class io.grpc.lb.v1.ServerList
- isInitialized() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
- isInitialized() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys.Builder
- isInitialized() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys
- isInitialized() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder
- isInitialized() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Name.Builder
- isInitialized() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Name
- isInitialized() - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
- isInitialized() - Method in class io.grpc.lookup.v1.HttpKeyBuilder
- isInitialized() - Method in class io.grpc.lookup.v1.NameMatcher.Builder
- isInitialized() - Method in class io.grpc.lookup.v1.NameMatcher
- isInitialized() - Method in class io.grpc.lookup.v1.RouteLookupClusterSpecifier.Builder
- isInitialized() - Method in class io.grpc.lookup.v1.RouteLookupClusterSpecifier
- isInitialized() - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
- isInitialized() - Method in class io.grpc.lookup.v1.RouteLookupConfig
- isInitialized() - Method in class io.grpc.lookup.v1.RouteLookupRequest.Builder
- isInitialized() - Method in class io.grpc.lookup.v1.RouteLookupRequest
- isInitialized() - Method in class io.grpc.lookup.v1.RouteLookupResponse.Builder
- isInitialized() - Method in class io.grpc.lookup.v1.RouteLookupResponse
- isInitialized() - Method in class io.grpc.reflection.v1.ErrorResponse.Builder
- isInitialized() - Method in class io.grpc.reflection.v1.ErrorResponse
- isInitialized() - Method in class io.grpc.reflection.v1.ExtensionNumberResponse.Builder
- isInitialized() - Method in class io.grpc.reflection.v1.ExtensionNumberResponse
- isInitialized() - Method in class io.grpc.reflection.v1.ExtensionRequest.Builder
- isInitialized() - Method in class io.grpc.reflection.v1.ExtensionRequest
- isInitialized() - Method in class io.grpc.reflection.v1.FileDescriptorResponse.Builder
- isInitialized() - Method in class io.grpc.reflection.v1.FileDescriptorResponse
- isInitialized() - Method in class io.grpc.reflection.v1.ListServiceResponse.Builder
- isInitialized() - Method in class io.grpc.reflection.v1.ListServiceResponse
- isInitialized() - Method in class io.grpc.reflection.v1.ServerReflectionRequest.Builder
- isInitialized() - Method in class io.grpc.reflection.v1.ServerReflectionRequest
- isInitialized() - Method in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
- isInitialized() - Method in class io.grpc.reflection.v1.ServerReflectionResponse
- isInitialized() - Method in class io.grpc.reflection.v1.ServiceResponse.Builder
- isInitialized() - Method in class io.grpc.reflection.v1.ServiceResponse
- isInitialized() - Method in class io.grpc.reflection.v1alpha.ErrorResponse.Builder
- isInitialized() - Method in class io.grpc.reflection.v1alpha.ErrorResponse
- isInitialized() - Method in class io.grpc.reflection.v1alpha.ExtensionNumberResponse.Builder
- isInitialized() - Method in class io.grpc.reflection.v1alpha.ExtensionNumberResponse
- isInitialized() - Method in class io.grpc.reflection.v1alpha.ExtensionRequest.Builder
- isInitialized() - Method in class io.grpc.reflection.v1alpha.ExtensionRequest
- isInitialized() - Method in class io.grpc.reflection.v1alpha.FileDescriptorResponse.Builder
- isInitialized() - Method in class io.grpc.reflection.v1alpha.FileDescriptorResponse
- isInitialized() - Method in class io.grpc.reflection.v1alpha.ListServiceResponse.Builder
- isInitialized() - Method in class io.grpc.reflection.v1alpha.ListServiceResponse
- isInitialized() - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest.Builder
- isInitialized() - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest
- isInitialized() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
- isInitialized() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse
- isInitialized() - Method in class io.grpc.reflection.v1alpha.ServiceResponse.Builder
- isInitialized() - Method in class io.grpc.reflection.v1alpha.ServiceResponse
- isInPanicMode() - Method in class io.grpc.internal.ManagedChannelImpl
- isInUse() - Method in class io.grpc.internal.InUseStateAggregator
- isJava9AlpnAvailable() - Static method in class io.grpc.netty.JettyTlsUtil
-
Indicates whether Java 9 ALPN is available.
- isJettyAlpnConfigured() - Static method in class io.grpc.netty.JettyTlsUtil
-
Indicates whether or not the Jetty ALPN jar is installed in the boot classloader.
- isJettyNpnConfigured() - Static method in class io.grpc.netty.JettyTlsUtil
-
Indicates whether or not the Jetty NPN jar is installed in the boot classloader.
- isLoggable(Level) - Method in interface io.grpc.servlet.AsyncServletOutputStreamWriter.Log
- isLoggable(Level) - Method in interface io.grpc.servlet.jakarta.AsyncServletOutputStreamWriter.Log
- isNonExistent() - Method in class io.grpc.netty.NettyClientStream.TransportState
- isOk() - Method in class io.grpc.Status
-
Is this status OK, i.e., not an error.
- isOldEnoughToBeEvicted(long) - Method in class io.grpc.rls.CachingRlsLbClient.CacheEntry
- isOldEnoughToBeEvicted(long) - Method in class io.grpc.rls.CachingRlsLbClient.DataCacheEntry
- isOutboundClosed() - Method in class io.grpc.internal.AbstractClientStream.TransportState
- isPassComplete() - Method in class io.grpc.internal.PickFirstLeafLoadBalancer
- isPending() - Method in class io.grpc.rls.CachingRlsLbClient.CachedRouteLookupResponse
- isPending() - Method in class io.grpc.SynchronizationContext.ScheduledHandle
-
Returns
true
if the task will eventually run, meaning that it has neither started running nor been cancelled. - isPingAllowed() - Method in class io.grpc.netty.AbstractNettyHandler.AllowPingLimiter
- isPingAllowed() - Method in interface io.grpc.netty.AbstractNettyHandler.PingLimiter
- isPingAllowed() - Method in class io.grpc.netty.NettyClientHandler.PingCountingFrameWriter
- isPinging() - Method in class io.grpc.netty.AbstractNettyHandler.FlowControlPinger
- isPresent() - Static method in class io.grpc.internal.ConscryptLoader
-
Returns
true
when the Conscrypt Java classes are available. - isPseudoHeader(AsciiString) - Static method in class io.grpc.netty.GrpcHttp2HeadersUtils.GrpcHttp2InboundHeaders
- isRateValid(double) - Static method in class io.grpc.services.MetricRecorderHelper
-
Return true if a rate value (such as qps or eps) is in the range [0, inf) and false otherwise.
- isReady - Variable in class io.grpc.servlet.AsyncServletOutputStreamWriter
- isReady - Variable in class io.grpc.servlet.jakarta.AsyncServletOutputStreamWriter
- 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.inprocess.InProcessTransport.InProcessStream.InProcessClientStream
- isReady() - Method in class io.grpc.inprocess.InProcessTransport.InProcessStream.InProcessServerStream
- 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.AbstractStream.TransportState
- isReady() - Method in class io.grpc.internal.ClientCallImpl
- isReady() - Method in class io.grpc.internal.DelayedClientCall
- isReady() - Method in class io.grpc.internal.DelayedStream
- isReady() - Method in class io.grpc.internal.ForwardingClientStream
- isReady() - Method in class io.grpc.internal.NoopClientStream
- isReady() - Method in class io.grpc.internal.RetriableStream
- isReady() - Method in class io.grpc.internal.ServerCallImpl
- 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.PartialForwardingClientCall
- isReady() - Method in class io.grpc.PartialForwardingServerCall
- isReady() - Method in class io.grpc.ServerCall
-
If
true
, indicates that the call is capable of sending additional messages without requiring excessive buffering internally. - isReady() - Method in class io.grpc.ServerStreamTracer.ReadOnlyServerCall
-
Deprecated.
- isReady() - Method in class io.grpc.stub.CallStreamObserver
-
If
true
, indicates that the observer is capable of sending additional messages without requiring excessive buffering internally. - isReady() - Method in class io.grpc.stub.ClientCalls.CallToStreamObserverAdapter
- isReady() - Method in class io.grpc.stub.ClientCallStreamObserver
-
If
true
, indicates that the observer is capable of sending additional messages without requiring excessive buffering internally. - isReady() - Method in class io.grpc.stub.ServerCalls.ServerCallStreamObserverImpl
- isReady() - Method in class io.grpc.stub.ServerCallStreamObserver
-
If
true
, indicates that the observer is capable of sending additional messages without requiring excessive buffering internally. - isReady() - Method in class io.grpc.util.TransmitStatusRuntimeExceptionInterceptor.SerializingServerCall
- isReleased() - Method in class io.grpc.rls.LbPolicyConfiguration.RefCountedChildPolicyWrapper
- isRetryTimerPending() - Method in class io.grpc.protobuf.services.HealthCheckingLoadBalancerFactory.HealthCheckState
- 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.
- isSerializingRetries() - Static method in class io.grpc.internal.PickFirstLeafLoadBalancer
- isServiceGlob(String) - Static method in class io.grpc.protobuf.services.BinlogHelper.FactoryImpl
-
Returns true if the input string is a glob of the form:
<package-service>/*
. - isShutdown() - Method in class io.grpc.internal.ForwardingManagedChannel
- isShutdown() - Method in class io.grpc.internal.ManagedChannelImpl
- isShutdown() - Method in class io.grpc.internal.ManagedChannelImpl.RestrictedScheduledExecutor
- isShutdown() - Method in class io.grpc.internal.OobChannel
- 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.
- isSpecCompliantAscii(byte[]) - Static method in class io.grpc.internal.TransportFrameUtil
-
Returns
true
ifsubject
contains only bytes that are spec-compliant ASCII characters and space. - isSpecificExecutorRequired() - Method in interface io.grpc.InternalMayRequireSpecificExecutor
- isStaled(long) - Method in class io.grpc.rls.CachingRlsLbClient.DataCacheEntry
- isStalled - Variable in class io.grpc.internal.GzipInflatingBuffer
- isStalled() - Method in class io.grpc.internal.GzipInflatingBuffer
-
Returns true when more bytes must be added via
GzipInflatingBuffer.addGzippedBytes(io.grpc.internal.ReadableBuffer)
to enable additional calls toGzipInflatingBuffer.inflateBytes(byte[], int, int)
to make progress. - isStalled() - Method in class io.grpc.internal.MessageDeframer
- isStreamDeallocated() - Method in class io.grpc.internal.AbstractStream.TransportState
- isTerminated() - Method in class io.grpc.internal.ForwardingManagedChannel
- isTerminated() - Method in class io.grpc.internal.ManagedChannelImpl
- isTerminated() - Method in class io.grpc.internal.ManagedChannelImpl.RestrictedScheduledExecutor
- isTerminated() - Method in class io.grpc.internal.OobChannel
- 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.
- isTraceable(ChannelLogger.ChannelLogLevel) - Method in class io.grpc.internal.ChannelLoggerImpl
- isTraceEnabled() - Method in class io.grpc.internal.ChannelTracer
- isTransparentRetry - Variable in class io.grpc.ClientStreamTracer.StreamInfo.Builder
- isTransparentRetry - Variable in class io.grpc.ClientStreamTracer.StreamInfo
- isTransparentRetry() - Method in class io.grpc.ClientStreamTracer.StreamInfo
-
Whether the stream is a transparent retry.
- isUtilizationValid(double) - Static method in class io.grpc.services.MetricRecorderHelper
-
Return true if the utilization value is in the range [0, 1] and false otherwise.
- isValid() - Method in class io.grpc.internal.InternalSubchannel.Index
- isValid() - Method in class io.grpc.internal.PickFirstLeafLoadBalancer.Index
- isValueReceived - Variable in class io.grpc.stub.ClientCalls.UnaryStreamToFuture
- isWaitForReady() - Method in class io.grpc.CallOptions
-
Returns whether 'wait for ready' option is enabled for the call.
- IterableAt(Metadata.Key<T>, int) - Constructor for class io.grpc.Metadata.IterableAt
- iterableContains(Iterable<T>, T) - Static method in class io.grpc.internal.GrpcUtil
-
Checks whether the given item exists in the iterable.
- iterator() - Method in class io.grpc.Metadata.IterableAt
- iterator() - Method in class io.grpc.netty.AbstractHttp2Headers
- iterator() - Method in class io.grpc.netty.GrpcHttp2HeadersUtils.GrpcHttp2InboundHeaders
- iterator() - Method in class io.grpc.netty.GrpcHttp2OutboundHeaders
- Itr() - Constructor for class io.grpc.netty.GrpcHttp2OutboundHeaders.Itr
J
- Java9AlpnUnavailabilityCauseHolder() - Constructor for class io.grpc.netty.JettyTlsUtil.Java9AlpnUnavailabilityCauseHolder
- JdkAddressResolver() - Constructor for enum io.grpc.internal.DnsNameResolver.JdkAddressResolver
- jettyAlpnUnavailabilityCause - Static variable in class io.grpc.netty.JettyTlsUtil
- jettyNpnUnavailabilityCause - Static variable in class io.grpc.netty.JettyTlsUtil
- JettyTlsUtil - Class in io.grpc.netty
-
Utility class for determining support for Jetty TLS ALPN/NPN.
- JettyTlsUtil() - Constructor for class io.grpc.netty.JettyTlsUtil
- JettyTlsUtil.Java9AlpnUnavailabilityCauseHolder - Class in io.grpc.netty
- jitter - Variable in class io.grpc.internal.ExponentialBackoffPolicy
- JNDI_LOCALHOST_PROPERTY - Static variable in class io.grpc.internal.DnsNameResolver
- JNDI_PROPERTY - Static variable in class io.grpc.internal.DnsNameResolver
- JNDI_TXT_PROPERTY - Static variable in class io.grpc.internal.DnsNameResolver
- JNDI_UNAVAILABILITY_CAUSE - Static variable in class io.grpc.internal.JndiResourceResolverFactory
- JndiRecordFetcher() - Constructor for class io.grpc.internal.JndiResourceResolverFactory.JndiRecordFetcher
- JndiResourceResolver(JndiResourceResolverFactory.RecordFetcher) - Constructor for class io.grpc.internal.JndiResourceResolverFactory.JndiResourceResolver
- JndiResourceResolverFactory - Class in io.grpc.internal
-
JndiResourceResolverFactory
resolves additional records for the DnsNameResolver. - JndiResourceResolverFactory() - Constructor for class io.grpc.internal.JndiResourceResolverFactory
- JndiResourceResolverFactory.JndiRecordFetcher - Class in io.grpc.internal
- JndiResourceResolverFactory.JndiResourceResolver - Class in io.grpc.internal
- JndiResourceResolverFactory.RecordFetcher - Interface in io.grpc.internal
- JsonParser - Class in io.grpc.internal
-
Parses JSON with as few preconceived notions as possible.
- JsonParser() - Constructor for class io.grpc.internal.JsonParser
- JsonUtil - Class in io.grpc.internal
-
Helper utility to work with JSON values in Java types.
- JsonUtil() - Constructor for class io.grpc.internal.JsonUtil
- JumpToApplicationThreadServerStreamListener(Executor, Executor, ServerStream, Context.CancellableContext, Tag) - Constructor for class io.grpc.internal.ServerImpl.JumpToApplicationThreadServerStreamListener
K
- KEEP_ALIVES_SENT_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.SocketData
- KEEPALIVE_PING - Static variable in class io.grpc.netty.NettyServerHandler
- KEEPALIVE_TIME_NANOS_DISABLED - Static variable in class io.grpc.internal.GrpcUtil
-
The magic keepalive time value that disables client keepalive.
- keepAliveBackoff - Variable in class io.grpc.netty.NettyChannelBuilder.NettyTransportFactory
- keepAliveDuringTransportIdle - Variable in class io.grpc.internal.KeepAliveManager
- keepAliveEnforcer - Variable in class io.grpc.netty.NettyServerHandler
- keepAliveEnforcer - Variable in class io.grpc.netty.NettyServerHandler.WriteMonitoringFrameWriter
- KeepAliveEnforcer - Class in io.grpc.internal
-
Monitors the client's PING usage to make sure the rate is permitted.
- KeepAliveEnforcer(boolean, long, TimeUnit) - Constructor for class io.grpc.internal.KeepAliveEnforcer
- KeepAliveEnforcer(boolean, long, TimeUnit, KeepAliveEnforcer.Ticker) - Constructor for class io.grpc.internal.KeepAliveEnforcer
- KeepAliveEnforcer.SystemTicker - Class in io.grpc.internal
- KeepAliveEnforcer.Ticker - Interface in io.grpc.internal
- keepAliveManager - Variable in class io.grpc.netty.NettyClientHandler
- keepAliveManager - Variable in class io.grpc.netty.NettyClientTransport
- keepAliveManager - Variable in class io.grpc.netty.NettyServerHandler
- keepAliveManager() - Method in class io.grpc.netty.NettyClientTransport
- KeepAliveManager - Class in io.grpc.internal
-
Manages keepalive pings.
- KeepAliveManager(KeepAliveManager.KeepAlivePinger, ScheduledExecutorService, long, long, boolean) - Constructor for class io.grpc.internal.KeepAliveManager
-
Creates a KeepAliverManager.
- KeepAliveManager(KeepAliveManager.KeepAlivePinger, ScheduledExecutorService, Stopwatch, long, long, boolean) - Constructor for class io.grpc.internal.KeepAliveManager
- KeepAliveManager.ClientKeepAlivePinger - Class in io.grpc.internal
-
Default client side
KeepAliveManager.KeepAlivePinger
. - KeepAliveManager.KeepAlivePinger - Interface in io.grpc.internal
- KeepAliveManager.State - Enum in io.grpc.internal
- keepAlivePinger - Variable in class io.grpc.internal.KeepAliveManager
- KeepAlivePinger(ChannelHandlerContext) - Constructor for class io.grpc.netty.NettyServerHandler.KeepAlivePinger
- keepAlivesSent - Variable in class io.grpc.internal.TransportTracer
- keepAlivesSent - Variable in class io.grpc.InternalChannelz.TransportStats
- keepAlivesSent_ - Variable in class io.grpc.channelz.v1.SocketData.Builder
- keepAlivesSent_ - Variable in class io.grpc.channelz.v1.SocketData
- keepAliveTime(long, TimeUnit) - Method in class io.grpc.ForwardingChannelBuilder
- keepAliveTime(long, TimeUnit) - Method in class io.grpc.ForwardingChannelBuilder2
- keepAliveTime(long, TimeUnit) - Method in class io.grpc.ForwardingServerBuilder
- keepAliveTime(long, TimeUnit) - Method in class io.grpc.inprocess.InProcessChannelBuilder
-
Does nothing.
- keepAliveTime(long, TimeUnit) - Method in class io.grpc.ManagedChannelBuilder
-
Sets the time without read activity before sending a keepalive ping.
- keepAliveTime(long, TimeUnit) - Method in class io.grpc.netty.NettyChannelBuilder
-
Sets the time without read activity before sending a keepalive ping.
- keepAliveTime(long, TimeUnit) - Method in class io.grpc.netty.NettyServerBuilder
-
Sets a custom keepalive time, the delay time for sending next keepalive ping.
- keepAliveTime(long, TimeUnit) - Method in class io.grpc.ServerBuilder
-
Sets the time without read activity before sending a keepalive ping.
- keepAliveTimeInNanos - Variable in class io.grpc.internal.KeepAliveManager
- keepAliveTimeInNanos - Variable in class io.grpc.netty.NettyServer
- keepAliveTimeInNanos - Variable in class io.grpc.netty.NettyServerBuilder
- keepAliveTimeInNanos - Variable in class io.grpc.netty.NettyServerHandler
- keepAliveTimeInNanos - Variable in class io.grpc.netty.NettyServerTransport
- keepAliveTimeNanos - Variable in class io.grpc.netty.NettyChannelBuilder
- keepAliveTimeNanos - Variable in class io.grpc.netty.NettyChannelBuilder.NettyTransportFactory
- keepAliveTimeNanos - Variable in class io.grpc.netty.NettyClientTransport
- keepAliveTimeout(long, TimeUnit) - Method in class io.grpc.ForwardingChannelBuilder
- keepAliveTimeout(long, TimeUnit) - Method in class io.grpc.ForwardingChannelBuilder2
- keepAliveTimeout(long, TimeUnit) - Method in class io.grpc.ForwardingServerBuilder
- keepAliveTimeout(long, TimeUnit) - Method in class io.grpc.inprocess.InProcessChannelBuilder
-
Does nothing.
- keepAliveTimeout(long, TimeUnit) - Method in class io.grpc.ManagedChannelBuilder
-
Sets the time waiting for read activity after sending a keepalive ping.
- keepAliveTimeout(long, TimeUnit) - Method in class io.grpc.netty.NettyChannelBuilder
-
Sets the time waiting for read activity after sending a keepalive ping.
- keepAliveTimeout(long, TimeUnit) - Method in class io.grpc.netty.NettyServerBuilder
-
Sets a custom keepalive timeout, the timeout for keepalive ping requests.
- keepAliveTimeout(long, TimeUnit) - Method in class io.grpc.ServerBuilder
-
Sets a time waiting for read activity after sending a keepalive ping.
- keepAliveTimeoutInNanos - Variable in class io.grpc.internal.KeepAliveManager
- keepAliveTimeoutInNanos - Variable in class io.grpc.netty.NettyServer
- keepAliveTimeoutInNanos - Variable in class io.grpc.netty.NettyServerBuilder
- keepAliveTimeoutInNanos - Variable in class io.grpc.netty.NettyServerHandler
- keepAliveTimeoutInNanos - Variable in class io.grpc.netty.NettyServerTransport
- keepAliveTimeoutNanos - Variable in class io.grpc.netty.NettyChannelBuilder
- keepAliveTimeoutNanos - Variable in class io.grpc.netty.NettyChannelBuilder.NettyTransportFactory
- keepAliveTimeoutNanos - Variable in class io.grpc.netty.NettyClientTransport
- keepAliveWithoutCalls - Variable in class io.grpc.netty.NettyChannelBuilder
- keepAliveWithoutCalls - Variable in class io.grpc.netty.NettyChannelBuilder.NettyTransportFactory
- keepAliveWithoutCalls - Variable in class io.grpc.netty.NettyClientTransport
- keepAliveWithoutCalls(boolean) - Method in class io.grpc.ForwardingChannelBuilder
- keepAliveWithoutCalls(boolean) - Method in class io.grpc.ForwardingChannelBuilder2
- keepAliveWithoutCalls(boolean) - Method in class io.grpc.inprocess.InProcessChannelBuilder
-
Does nothing.
- keepAliveWithoutCalls(boolean) - Method in class io.grpc.ManagedChannelBuilder
-
Sets whether keepalive will be performed when there are no outstanding RPC on a connection.
- keepAliveWithoutCalls(boolean) - Method in class io.grpc.netty.NettyChannelBuilder
-
Sets whether keepalive will be performed when there are no outstanding RPC on a connection.
- key - Variable in class io.grpc.Metadata.IterableAt
- key - Variable in class io.grpc.netty.GrpcHttp2OutboundHeaders.Itr
- key - Variable in class io.grpc.PersistentHashArrayMappedTrie.Leaf
- key - Variable in class io.grpc.rls.AutoValue_RlsProtoData_NameMatcher
- key - Variable in class io.grpc.util.AdvancedTlsX509KeyManager.KeyInfo
- key - Variable in class io.grpc.util.MultiChildLoadBalancer.ChildLbState
- key() - Method in class io.grpc.rls.AutoValue_RlsProtoData_NameMatcher
- key() - Method in class io.grpc.rls.RlsProtoData.NameMatcher
-
The name that will be used in the RLS key_map to refer to this value.
- key(String) - Static method in class io.grpc.Context
-
Create a
Context.Key
with the given debug name. - Key(String) - Constructor for class io.grpc.Attributes.Key
- Key(String) - Constructor for class io.grpc.Context.Key
- Key(String, boolean, Object) - Constructor for class io.grpc.Metadata.Key
- Key(String, T) - Constructor for class io.grpc.CallOptions.Key
- Key(String, T) - Constructor for class io.grpc.Context.Key
- Key(String, T) - Constructor for class io.grpc.LoadBalancer.CreateSubchannelArgs.Key
- KEY - Static variable in class io.grpc.internal.ManagedChannelServiceConfig.MethodInfo
- KEY - Static variable in class io.grpc.InternalConfigSelector
- key_ - Variable in class io.grpc.binarylog.v1.MetadataEntry.Builder
- key_ - Variable in class io.grpc.binarylog.v1.MetadataEntry
- key_ - Variable in class io.grpc.lookup.v1.NameMatcher.Builder
- key_ - Variable in class io.grpc.lookup.v1.NameMatcher
- KEY_FIELD_NUMBER - Static variable in class io.grpc.binarylog.v1.MetadataEntry
- KEY_FIELD_NUMBER - Static variable in class io.grpc.lookup.v1.NameMatcher
- KEY_MAP_FIELD_NUMBER - Static variable in class io.grpc.lookup.v1.RouteLookupRequest
- keyBuilderTable - Variable in class io.grpc.rls.RlsRequestFactory
- keyFile - Variable in class io.grpc.util.AdvancedTlsX509KeyManager.LoadFilePathExecution
- keyForProto(T) - Static method in class io.grpc.protobuf.ProtoUtils
-
Produce a metadata key for a generated protobuf type.
- keyInfo - Variable in class io.grpc.util.AdvancedTlsX509KeyManager
- KeyInfo(X509Certificate[], PrivateKey) - Constructor for class io.grpc.util.AdvancedTlsX509KeyManager.KeyInfo
- keyManager(File, File) - Method in class io.grpc.TlsChannelCredentials.Builder
-
Use the provided certificate chain and private key as the client's identity.
- keyManager(File, File) - Method in class io.grpc.TlsServerCredentials.Builder
-
Use the provided certificate chain and private key as the server's identity.
- keyManager(File, File, String) - Method in class io.grpc.TlsChannelCredentials.Builder
-
Use the provided certificate chain and possibly-encrypted private key as the client's identity.
- keyManager(File, File, String) - Method in class io.grpc.TlsServerCredentials.Builder
-
Use the provided certificate chain and possibly-encrypted private key as the server's identity.
- keyManager(InputStream, InputStream) - Method in class io.grpc.TlsChannelCredentials.Builder
-
Use the provided certificate chain and private key as the client's identity.
- keyManager(InputStream, InputStream) - Method in class io.grpc.TlsServerCredentials.Builder
-
Use the provided certificate chain and private key as the server's identity.
- keyManager(InputStream, InputStream, String) - Method in class io.grpc.TlsChannelCredentials.Builder
-
Use the provided certificate chain and possibly-encrypted private key as the client's identity.
- keyManager(InputStream, InputStream, String) - Method in class io.grpc.TlsServerCredentials.Builder
-
Use the provided certificate chain and possibly-encrypted private key as the server's identity.
- keyManager(KeyManager...) - Method in class io.grpc.TlsChannelCredentials.Builder
-
Have the provided key manager select the client's identity.
- keyManager(KeyManager...) - Method in class io.grpc.TlsServerCredentials.Builder
-
Have the provided key manager select the server's identity.
- keyManagers - Variable in class io.grpc.netty.FixedKeyManagerFactory.FixedKeyManagerFactorySpi
- keyManagers - Variable in class io.grpc.TlsChannelCredentials.Builder
- keyManagers - Variable in class io.grpc.TlsChannelCredentials
- keyManagers - Variable in class io.grpc.TlsServerCredentials.Builder
- keyManagers - Variable in class io.grpc.TlsServerCredentials
- keyMap - Variable in class io.grpc.rls.AutoValue_RlsProtoData_RouteLookupRequest
- keyMap() - Method in class io.grpc.rls.AutoValue_RlsProtoData_RouteLookupRequest
- keyMap() - Method in class io.grpc.rls.RlsProtoData.RouteLookupRequest
-
Returns a map of key values extracted via key builders for the gRPC or HTTP request.
- keyMap_ - Variable in class io.grpc.lookup.v1.RouteLookupRequest.Builder
- keyMap_ - Variable in class io.grpc.lookup.v1.RouteLookupRequest
- KeyMapDefaultEntryHolder() - Constructor for class io.grpc.lookup.v1.RouteLookupRequest.KeyMapDefaultEntryHolder
- keyOf(String, InternalMetadata.TrustedAsciiMarshaller<T>) - Static method in class io.grpc.InternalMetadata
- keyOf(String, Metadata.AsciiMarshaller<T>) - Static method in class io.grpc.InternalMetadata
- keys - Variable in class io.grpc.PersistentHashArrayMappedTrie.CollisionLeaf
- keys() - Method in class io.grpc.Attributes
-
Deprecated.This method is being considered for removal, if you feel this method is needed please reach out on this Github issue: grpc-java/issues/1764.
- keys() - Method in class io.grpc.Metadata
-
Returns set of all keys in store.
- keysForTest() - Method in class io.grpc.Attributes
- keyTime - Variable in class io.grpc.util.AdvancedTlsX509KeyManager.UpdateResult
- keyToString(RlsProtoData.ExtraKeys) - Static method in class io.grpc.rls.RlsProtoConverters.RouteLookupConfigConverter
- keyValueEntries - Variable in class io.grpc.Context
- keyWithDefault(String, T) - Static method in class io.grpc.Context
-
Create a
Context.Key
with the given debug name and default value. - KnownLength - Interface in io.grpc
-
An
InputStream
or alike whose total number of bytes that can be read is known upfront. - KnownLengthBufferedInputStream(InputStream) - Constructor for class io.grpc.ServerInterceptors.KnownLengthBufferedInputStream
- KTY_PARAMETER_VALUE - Static variable in class io.grpc.internal.SpiffeUtil
L
- last - Variable in class io.grpc.stub.ClientCalls.BlockingResponseStream
- LAST_CALL_STARTED_TIMESTAMP_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.ChannelData
- LAST_CALL_STARTED_TIMESTAMP_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.ServerData
- LAST_LOCAL_STREAM_CREATED_TIMESTAMP_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.SocketData
- LAST_MESSAGE_RECEIVED_TIMESTAMP_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.SocketData
- LAST_MESSAGE_SENT_TIMESTAMP_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.SocketData
- LAST_REMOTE_STREAM_CREATED_TIMESTAMP_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.SocketData
- lastAckRecv - Variable in class io.grpc.InternalChannelz.TcpInfo.Builder
- lastAckRecv - Variable in class io.grpc.InternalChannelz.TcpInfo
- lastAckSent - Variable in class io.grpc.InternalChannelz.TcpInfo.Builder
- lastAckSent - Variable in class io.grpc.InternalChannelz.TcpInfo
- lastBandwidth - Variable in class io.grpc.netty.AbstractNettyHandler.FlowControlPinger
- lastCallStartedNanos - Variable in class io.grpc.internal.CallTracer
- lastCallStartedNanos - Variable in class io.grpc.InternalChannelz.ChannelStats.Builder
- lastCallStartedNanos - Variable in class io.grpc.InternalChannelz.ChannelStats
- lastCallStartedNanos - Variable in class io.grpc.InternalChannelz.ServerStats.Builder
- lastCallStartedNanos - Variable in class io.grpc.InternalChannelz.ServerStats
- lastCallStartedTimestamp_ - Variable in class io.grpc.channelz.v1.ChannelData.Builder
- lastCallStartedTimestamp_ - Variable in class io.grpc.channelz.v1.ChannelData
- lastCallStartedTimestamp_ - Variable in class io.grpc.channelz.v1.ServerData.Builder
- lastCallStartedTimestamp_ - Variable in class io.grpc.channelz.v1.ServerData
- lastCallStartedTimestampBuilder_ - Variable in class io.grpc.channelz.v1.ChannelData.Builder
- lastCallStartedTimestampBuilder_ - Variable in class io.grpc.channelz.v1.ServerData.Builder
- lastDataRecv - Variable in class io.grpc.InternalChannelz.TcpInfo.Builder
- lastDataRecv - Variable in class io.grpc.InternalChannelz.TcpInfo
- lastDataSent - Variable in class io.grpc.InternalChannelz.TcpInfo.Builder
- lastDataSent - Variable in class io.grpc.InternalChannelz.TcpInfo
- lastKnownAuthority - Variable in class io.grpc.netty.NettyServerHandler
- lastLocalStreamCreatedTimeNanos - Variable in class io.grpc.internal.TransportTracer
- lastLocalStreamCreatedTimeNanos - Variable in class io.grpc.InternalChannelz.TransportStats
- lastLocalStreamCreatedTimestamp_ - Variable in class io.grpc.channelz.v1.SocketData.Builder
- lastLocalStreamCreatedTimestamp_ - Variable in class io.grpc.channelz.v1.SocketData
- lastLocalStreamCreatedTimestampBuilder_ - Variable in class io.grpc.channelz.v1.SocketData.Builder
- lastMessageReceivedTimeNanos - Variable in class io.grpc.internal.TransportTracer
- lastMessageReceivedTimeNanos - Variable in class io.grpc.InternalChannelz.TransportStats
- lastMessageReceivedTimestamp_ - Variable in class io.grpc.channelz.v1.SocketData.Builder
- lastMessageReceivedTimestamp_ - Variable in class io.grpc.channelz.v1.SocketData
- lastMessageReceivedTimestampBuilder_ - Variable in class io.grpc.channelz.v1.SocketData.Builder
- lastMessageSentTimeNanos - Variable in class io.grpc.internal.TransportTracer
- lastMessageSentTimeNanos - Variable in class io.grpc.InternalChannelz.TransportStats
- lastMessageSentTimestamp_ - Variable in class io.grpc.channelz.v1.SocketData.Builder
- lastMessageSentTimestamp_ - Variable in class io.grpc.channelz.v1.SocketData
- lastMessageSentTimestampBuilder_ - Variable in class io.grpc.channelz.v1.SocketData.Builder
- lastPicker - Variable in class io.grpc.internal.DelayedClientTransport.PickerState
-
The last picker that
DelayedClientTransport.reprocess(io.grpc.LoadBalancer.SubchannelPicker)
has used. - lastPingTime - Variable in class io.grpc.netty.AbstractNettyHandler.FlowControlPinger
- lastRemoteStreamCreatedTimeNanos - Variable in class io.grpc.internal.TransportTracer
- lastRemoteStreamCreatedTimeNanos - Variable in class io.grpc.InternalChannelz.TransportStats
- lastRemoteStreamCreatedTimestamp_ - Variable in class io.grpc.channelz.v1.SocketData.Builder
- lastRemoteStreamCreatedTimestamp_ - Variable in class io.grpc.channelz.v1.SocketData
- lastRemoteStreamCreatedTimestampBuilder_ - Variable in class io.grpc.channelz.v1.SocketData.Builder
- lastResolutionState - Variable in class io.grpc.internal.ManagedChannelImpl
- lastRstNanoTime - Variable in class io.grpc.netty.NettyServerHandler
- lastServiceConfig - Variable in class io.grpc.internal.ManagedChannelImpl
- lastSubchannelState - Variable in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionSubchannel
- lastTargetWindow - Variable in class io.grpc.netty.AbstractNettyHandler.FlowControlPinger
- lastValidPingTime - Variable in class io.grpc.internal.KeepAliveEnforcer
- later - Variable in class io.grpc.netty.WriteQueue
-
Runnable
used to schedule work onto the tail of the event loop. - LazyStorage() - Constructor for class io.grpc.Context.LazyStorage
- LazyStreamBinaryKey(String, Metadata.BinaryStreamMarshaller<T>) - Constructor for class io.grpc.Metadata.LazyStreamBinaryKey
-
Keys have a name and a stream marshaller used for serialization.
- LazyValue(Metadata.BinaryStreamMarshaller<T>, T) - Constructor for class io.grpc.Metadata.LazyValue
-
A value set by the application.
- lb - Variable in class io.grpc.internal.ManagedChannelImpl.LbHelperImpl
- lb - Variable in class io.grpc.rls.LbPolicyConfiguration.ChildPolicyWrapper
- lb - Variable in class io.grpc.util.MultiChildLoadBalancer.ChildLbState
- LB_PROVIDED_BACKEND_ATTRS - Static variable in class io.grpc.grpclb.GrpclbState
- lbCommChannel - Variable in class io.grpc.grpclb.GrpclbState
- LbConfig(String, Map<String, ?>) - Constructor for class io.grpc.internal.ServiceConfigUtil.LbConfig
- lbHelper - Variable in class io.grpc.internal.ManagedChannelImpl
- LbHelperImpl() - Constructor for class io.grpc.internal.ManagedChannelImpl.LbHelperImpl
- lbPolicyConfig - Variable in class io.grpc.rls.CachingRlsLbClient.Builder
- lbPolicyConfig - Variable in class io.grpc.rls.CachingRlsLbClient
- lbPolicyConfiguration - Variable in class io.grpc.rls.RlsLoadBalancer
- LbPolicyConfiguration - Class in io.grpc.rls
-
Configuration for RLS load balancing policy.
- LbPolicyConfiguration(RlsProtoData.RouteLookupConfig, Map<String, ?>, LbPolicyConfiguration.ChildLoadBalancingPolicy) - Constructor for class io.grpc.rls.LbPolicyConfiguration
- LbPolicyConfiguration.ChildLbStatusListener - Interface in io.grpc.rls
-
Listener for child lb status change events.
- LbPolicyConfiguration.ChildLoadBalancingPolicy - Class in io.grpc.rls
-
ChildLoadBalancingPolicy is an elected child policy to delegate requests.
- LbPolicyConfiguration.ChildPolicyWrapper - Class in io.grpc.rls
-
ChildPolicyWrapper is a wrapper class for child load balancing policy with associated helper / utility classes to manage the child policy.
- LbPolicyConfiguration.ChildPolicyWrapper.ChildPolicyReportingHelper - Class in io.grpc.rls
-
A delegating
LoadBalancer.Helper
maintains status ofLbPolicyConfiguration.ChildPolicyWrapper
whenLoadBalancer.Subchannel
status changed. - LbPolicyConfiguration.InvalidChildPolicyConfigException - Exception Class in io.grpc.rls
-
Exception thrown when attempting to parse child policy encountered parsing issue.
- LbPolicyConfiguration.RefCountedChildPolicyWrapper - Class in io.grpc.rls
- LbPolicyConfiguration.RefCountedChildPolicyWrapperFactory - Class in io.grpc.rls
-
Factory for
LbPolicyConfiguration.ChildPolicyWrapper
. - lbRequestWriter - Variable in class io.grpc.grpclb.GrpclbState.LbStream
- lbRpcRetryPolicy - Variable in class io.grpc.grpclb.GrpclbState
- LbRpcRetryTask() - Constructor for class io.grpc.grpclb.GrpclbState.LbRpcRetryTask
- lbRpcRetryTimer - Variable in class io.grpc.grpclb.GrpclbState
- lbStream - Variable in class io.grpc.grpclb.GrpclbState
- LbStream(LoadBalancerGrpc.LoadBalancerStub) - Constructor for class io.grpc.grpclb.GrpclbState.LbStream
- Leaf(K, V) - Constructor for class io.grpc.PersistentHashArrayMappedTrie.Leaf
- len() - Method in class io.grpc.Metadata
- length_ - Variable in class io.grpc.binarylog.v1.Message.Builder
- length_ - Variable in class io.grpc.binarylog.v1.Message
- LENGTH_FIELD_NUMBER - Static variable in class io.grpc.binarylog.v1.Message
- lifecycleManager - Variable in class io.grpc.netty.Http2ControlFrameLimitEncoder
- lifecycleManager - Variable in class io.grpc.netty.NettyClientHandler
- lifecycleManager - Variable in class io.grpc.netty.NettyClientTransport
-
Since not thread-safe, may only be used from event loop.
- lifecycleManager(Http2LifecycleManager) - Method in class io.grpc.netty.Http2ControlFrameLimitEncoder
- limitReached - Variable in class io.grpc.netty.Http2ControlFrameLimitEncoder
- lingerSeconds - Variable in class io.grpc.InternalChannelz.SocketOptions.Builder
- lingerSeconds - Variable in class io.grpc.InternalChannelz.SocketOptions
- link - Variable in class io.grpc.netty.SendGrpcFrameCommand
- link - Variable in class io.grpc.netty.WriteQueue.AbstractQueuedCommand
- link - Variable in class io.grpc.netty.WriteQueue.RunnableCommand
- linkedHashLruCache - Variable in class io.grpc.rls.CachingRlsLbClient
- LinkedHashLruCache<K,
V> - Class in io.grpc.rls -
A LinkedHashLruCache implements least recently used caching where it supports access order lru cache eviction while allowing entry level expiration time.
- LinkedHashLruCache(long, LruCache.EvictionListener<K, V>, Ticker) - Constructor for class io.grpc.rls.LinkedHashLruCache
- LinkedHashLruCache.SizedValue - Class in io.grpc.rls
- LinkedHashLruCache.SizeHandlingEvictionListener - Class in io.grpc.rls
-
A
LruCache.EvictionListener
keeps track of size. - LIST_SERVICES - Enum constant in enum io.grpc.reflection.v1.ServerReflectionRequest.MessageRequestCase
- LIST_SERVICES - Enum constant in enum io.grpc.reflection.v1alpha.ServerReflectionRequest.MessageRequestCase
- LIST_SERVICES_FIELD_NUMBER - Static variable in class io.grpc.reflection.v1.ServerReflectionRequest
- LIST_SERVICES_FIELD_NUMBER - Static variable in class io.grpc.reflection.v1alpha.ServerReflectionRequest
- LIST_SERVICES_RESPONSE - Enum constant in enum io.grpc.reflection.v1.ServerReflectionResponse.MessageResponseCase
- LIST_SERVICES_RESPONSE - Enum constant in enum io.grpc.reflection.v1alpha.ServerReflectionResponse.MessageResponseCase
- LIST_SERVICES_RESPONSE_FIELD_NUMBER - Static variable in class io.grpc.reflection.v1.ServerReflectionResponse
- LIST_SERVICES_RESPONSE_FIELD_NUMBER - Static variable in class io.grpc.reflection.v1alpha.ServerReflectionResponse
- LISTEN_SOCKET_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.Server
- listenAddress - Variable in class io.grpc.inprocess.InProcessServer
- listenAddress - Variable in class io.grpc.inprocess.InProcessServerBuilder
- listenAddresses - Variable in class io.grpc.netty.NettyServerBuilder
- listener - Variable in class io.grpc.Context.ExecutableListener
- listener - Variable in class io.grpc.grpclb.CachedSubchannelPool
- listener - Variable in class io.grpc.inprocess.InProcessServer
- listener - Variable in class io.grpc.internal.AbstractClientStream.TransportState
- listener - Variable in class io.grpc.internal.AbstractServerStream.TransportState
- listener - Variable in class io.grpc.internal.DelayedClientCall.CloseListenerRunnable
- listener - Variable in class io.grpc.internal.DelayedClientCall
-
Non-
null
iff start has been called. - listener - Variable in class io.grpc.internal.DelayedClientTransport
- listener - Variable in class io.grpc.internal.DelayedStream
-
Non-
null
iff start has been called. - listener - Variable in class io.grpc.internal.DnsNameResolver
- listener - Variable in class io.grpc.internal.MessageDeframer
- listener - Variable in class io.grpc.internal.MetadataApplierImpl
- listener - Variable in class io.grpc.internal.ServerCallImpl.ServerStreamListenerImpl
- listener - Variable in class io.grpc.internal.ServerImpl.JumpToApplicationThreadServerStreamListener
- listener - Variable in class io.grpc.netty.ClientTransportLifecycleManager
- listener - Variable in class io.grpc.netty.NettyServer
- listener - Variable in class io.grpc.netty.NettyServerTransport
- listener - Variable in class io.grpc.netty.UdsNameResolver
- listener - Variable in class io.grpc.rls.LbPolicyConfiguration.ChildPolicyWrapper.ChildPolicyReportingHelper
- listener - Variable in class io.grpc.stub.ClientCalls.BlockingResponseStream
- listener() - Method in class io.grpc.internal.AbstractClientStream.TransportState
- listener() - Method in class io.grpc.internal.AbstractServerStream.TransportState
- listener() - Method in class io.grpc.internal.AbstractStream.TransportState
-
Override this method to provide a stream listener.
- listener() - Method in class io.grpc.stub.ClientCalls.BlockingResponseStream
- Listener() - Constructor for class io.grpc.ClientCall.Listener
- Listener() - Constructor for class io.grpc.ServerCall.Listener
- Listener(Runnable, Executor) - Constructor for class io.grpc.internal.ConnectivityStateManager.Listener
- Listener2() - Constructor for class io.grpc.NameResolver.Listener2
- listenerClosed - Variable in class io.grpc.internal.AbstractClientStream.TransportState
- listenerClosed - Variable in class io.grpc.internal.AbstractServerStream.TransportState
-
Whether listener.closed() has been called.
- listenerCount() - Method in class io.grpc.Context.CancellableContext
- listenerCount() - Method in class io.grpc.Context
- listeners - Variable in class io.grpc.Context.CancellableContext
- listeners - Variable in class io.grpc.internal.ConnectivityStateManager
- listenerSerializeExecutor - Variable in class io.grpc.internal.RetriableStream
- ListenSocket(Channel) - Constructor for class io.grpc.netty.NettyServer.ListenSocket
- listenSocket_ - Variable in class io.grpc.channelz.v1.Server.Builder
- listenSocket_ - Variable in class io.grpc.channelz.v1.Server
- listenSocketBuilder_ - Variable in class io.grpc.channelz.v1.Server.Builder
- listenSockets - Variable in class io.grpc.InternalChannelz.ServerStats.Builder
- listenSockets - Variable in class io.grpc.InternalChannelz.ServerStats
- listenSocketStatsList - Variable in class io.grpc.netty.NettyServer
- ListServiceResponse - Class in io.grpc.reflection.v1
-
A list of ServiceResponse sent by the server answering list_services request.
- ListServiceResponse - Class in io.grpc.reflection.v1alpha
-
A list of ServiceResponse sent by the server answering list_services request.
- ListServiceResponse() - Constructor for class io.grpc.reflection.v1.ListServiceResponse
- ListServiceResponse() - Constructor for class io.grpc.reflection.v1alpha.ListServiceResponse
- ListServiceResponse(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.reflection.v1.ListServiceResponse
- ListServiceResponse(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.reflection.v1alpha.ListServiceResponse
- ListServiceResponse.Builder - Class in io.grpc.reflection.v1
-
A list of ServiceResponse sent by the server answering list_services request.
- ListServiceResponse.Builder - Class in io.grpc.reflection.v1alpha
-
A list of ServiceResponse sent by the server answering list_services request.
- ListServiceResponseOrBuilder - Interface in io.grpc.reflection.v1
- ListServiceResponseOrBuilder - Interface in io.grpc.reflection.v1alpha
- listServices(ServerReflectionRequest) - Method in class io.grpc.protobuf.services.ProtoReflectionServiceV1.ProtoReflectionStreamObserver
- listServicesResponseBuilder_ - Variable in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
- listServicesResponseBuilder_ - Variable in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
- load(Class<T>, Iterable<Class<?>>, ClassLoader, InternalServiceProviders.PriorityAccessor<T>) - Static method in class io.grpc.InternalServiceProviders
-
Accessor for method.
- load(Class<T>, Iterable<Class<?>>, ClassLoader, ServiceProviders.PriorityAccessor<T>) - Static method in class io.grpc.ServiceProviders
-
If this is not Android, returns the highest priority implementation of the class via
ServiceLoader
. - LOAD_BALANCE_TOKEN_FIELD_NUMBER - Static variable in class io.grpc.lb.v1.ClientStatsPerToken
- LOAD_BALANCE_TOKEN_FIELD_NUMBER - Static variable in class io.grpc.lb.v1.Server
- LOAD_BALANCING - Enum constant in enum io.grpc.grpclb.DropType
- loadAll(Class<T>, Iterable<Class<?>>, ClassLoader, InternalServiceProviders.PriorityAccessor<T>) - Static method in class io.grpc.InternalServiceProviders
-
Accessor for method.
- loadAll(Class<T>, Iterable<Class<?>>, ClassLoader, ServiceProviders.PriorityAccessor<T>) - Static method in class io.grpc.ServiceProviders
-
If this is not Android, returns all available implementations discovered via
ServiceLoader
. - LoadBalancer - Class in io.grpc
-
A pluggable component that receives resolved addresses from
NameResolver
and provides the channel a usable subchannel when asked. - LoadBalancer() - Constructor for class io.grpc.LoadBalancer
- LoadBalancer.CreateSubchannelArgs - Class in io.grpc
-
Arguments for creating a
LoadBalancer.Subchannel
. - LoadBalancer.CreateSubchannelArgs.Builder - Class in io.grpc
- LoadBalancer.CreateSubchannelArgs.Key<T> - Class in io.grpc
-
Key for a key-value pair.
- LoadBalancer.ErrorPicker - Class in io.grpc
-
Deprecated.Use
new FixedResultPicker(PickResult.withError(error))
instead. - LoadBalancer.Factory - Class in io.grpc
-
Factory to create
LoadBalancer
instance. - LoadBalancer.FixedResultPicker - Class in io.grpc
-
A picker that always returns the same result.
- LoadBalancer.Helper - Class in io.grpc
-
Provides essentials for LoadBalancer implementations.
- LoadBalancer.PickDetailsConsumer - Interface in io.grpc
-
Receives information about the pick being chosen.
- LoadBalancer.PickResult - Class in io.grpc
-
A balancing decision made by
SubchannelPicker
for an RPC. - LoadBalancer.PickSubchannelArgs - Class in io.grpc
-
Provides arguments for a
LoadBalancer.SubchannelPicker.pickSubchannel(LoadBalancer.PickSubchannelArgs)
. - LoadBalancer.ResolvedAddresses - Class in io.grpc
-
Represents a combination of the resolved server address, associated attributes and a load balancing policy config.
- LoadBalancer.ResolvedAddresses.Builder - Class in io.grpc
-
Builder for
LoadBalancer.ResolvedAddresses
. - LoadBalancer.Subchannel - Class in io.grpc
-
A logical connection to a server, or a group of equivalent servers represented by an
EquivalentAddressGroup
. - LoadBalancer.SubchannelPicker - Class in io.grpc
-
The main balancing logic.
- LoadBalancer.SubchannelStateListener - Interface in io.grpc
-
Receives state changes for one
LoadBalancer.Subchannel
. - LoadBalancerBaseDescriptorSupplier() - Constructor for class io.grpc.lb.v1.LoadBalancerGrpc.LoadBalancerBaseDescriptorSupplier
- LoadBalancerBlockingStub(Channel, CallOptions) - Constructor for class io.grpc.lb.v1.LoadBalancerGrpc.LoadBalancerBlockingStub
- LoadBalanceRequest - Class in io.grpc.lb.v1
-
Protobuf type
grpc.lb.v1.LoadBalanceRequest
- LoadBalanceRequest() - Constructor for class io.grpc.lb.v1.LoadBalanceRequest
- LoadBalanceRequest(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.lb.v1.LoadBalanceRequest
- LoadBalanceRequest.Builder - Class in io.grpc.lb.v1
-
Protobuf type
grpc.lb.v1.LoadBalanceRequest
- LoadBalanceRequest.LoadBalanceRequestTypeCase - Enum in io.grpc.lb.v1
- LoadBalanceRequestOrBuilder - Interface in io.grpc.lb.v1
- loadBalanceRequestType_ - Variable in class io.grpc.lb.v1.LoadBalanceRequest.Builder
- loadBalanceRequestType_ - Variable in class io.grpc.lb.v1.LoadBalanceRequest
- LOADBALANCEREQUESTTYPE_NOT_SET - Enum constant in enum io.grpc.lb.v1.LoadBalanceRequest.LoadBalanceRequestTypeCase
- LoadBalanceRequestTypeCase(int) - Constructor for enum io.grpc.lb.v1.LoadBalanceRequest.LoadBalanceRequestTypeCase
- loadBalanceRequestTypeCase_ - Variable in class io.grpc.lb.v1.LoadBalanceRequest.Builder
- loadBalanceRequestTypeCase_ - Variable in class io.grpc.lb.v1.LoadBalanceRequest
- LoadBalanceResponse - Class in io.grpc.lb.v1
-
Protobuf type
grpc.lb.v1.LoadBalanceResponse
- LoadBalanceResponse() - Constructor for class io.grpc.lb.v1.LoadBalanceResponse
- LoadBalanceResponse(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.lb.v1.LoadBalanceResponse
- LoadBalanceResponse.Builder - Class in io.grpc.lb.v1
-
Protobuf type
grpc.lb.v1.LoadBalanceResponse
- LoadBalanceResponse.LoadBalanceResponseTypeCase - Enum in io.grpc.lb.v1
- LoadBalanceResponseOrBuilder - Interface in io.grpc.lb.v1
- loadBalanceResponseType_ - Variable in class io.grpc.lb.v1.LoadBalanceResponse.Builder
- loadBalanceResponseType_ - Variable in class io.grpc.lb.v1.LoadBalanceResponse
- LOADBALANCERESPONSETYPE_NOT_SET - Enum constant in enum io.grpc.lb.v1.LoadBalanceResponse.LoadBalanceResponseTypeCase
- LoadBalanceResponseTypeCase(int) - Constructor for enum io.grpc.lb.v1.LoadBalanceResponse.LoadBalanceResponseTypeCase
- loadBalanceResponseTypeCase_ - Variable in class io.grpc.lb.v1.LoadBalanceResponse.Builder
- loadBalanceResponseTypeCase_ - Variable in class io.grpc.lb.v1.LoadBalanceResponse
- loadBalancerFactory - Variable in class io.grpc.internal.ManagedChannelImpl
- LoadBalancerFileDescriptorSupplier() - Constructor for class io.grpc.lb.v1.LoadBalancerGrpc.LoadBalancerFileDescriptorSupplier
- LoadBalancerFutureStub(Channel, CallOptions) - Constructor for class io.grpc.lb.v1.LoadBalancerGrpc.LoadBalancerFutureStub
- LoadBalancerGrpc - Class in io.grpc.lb.v1
- LoadBalancerGrpc() - Constructor for class io.grpc.lb.v1.LoadBalancerGrpc
- LoadBalancerGrpc.AsyncService - Interface in io.grpc.lb.v1
- LoadBalancerGrpc.LoadBalancerBaseDescriptorSupplier - Class in io.grpc.lb.v1
- LoadBalancerGrpc.LoadBalancerBlockingStub - Class in io.grpc.lb.v1
-
A stub to allow clients to do synchronous rpc calls to service LoadBalancer.
- LoadBalancerGrpc.LoadBalancerFileDescriptorSupplier - Class in io.grpc.lb.v1
- LoadBalancerGrpc.LoadBalancerFutureStub - Class in io.grpc.lb.v1
-
A stub to allow clients to do ListenableFuture-style rpc calls to service LoadBalancer.
- LoadBalancerGrpc.LoadBalancerImplBase - Class in io.grpc.lb.v1
-
Base class for the server implementation of the service LoadBalancer.
- LoadBalancerGrpc.LoadBalancerMethodDescriptorSupplier - Class in io.grpc.lb.v1
- LoadBalancerGrpc.LoadBalancerStub - Class in io.grpc.lb.v1
-
A stub to allow clients to do asynchronous rpc calls to service LoadBalancer.
- LoadBalancerGrpc.MethodHandlers<Req,
Resp> - Class in io.grpc.lb.v1 - LoadBalancerImplBase() - Constructor for class io.grpc.lb.v1.LoadBalancerGrpc.LoadBalancerImplBase
- LoadBalancerMethodDescriptorSupplier(String) - Constructor for class io.grpc.lb.v1.LoadBalancerGrpc.LoadBalancerMethodDescriptorSupplier
- LoadBalancerPriorityAccessor() - Constructor for class io.grpc.LoadBalancerRegistry.LoadBalancerPriorityAccessor
- LoadBalancerProto - Class in io.grpc.lb.v1
- LoadBalancerProto() - Constructor for class io.grpc.lb.v1.LoadBalancerProto
- LoadBalancerProvider - Class in io.grpc
-
Provider of
LoadBalancer
s. - LoadBalancerProvider() - Constructor for class io.grpc.LoadBalancerProvider
- LoadBalancerProvider.UnknownConfig - Class in io.grpc
- LoadBalancerRegistry - Class in io.grpc
-
Registry of
LoadBalancerProvider
s. - LoadBalancerRegistry() - Constructor for class io.grpc.LoadBalancerRegistry
- LoadBalancerRegistry.LoadBalancerPriorityAccessor - Class in io.grpc
- LoadBalancerStub(Channel, CallOptions) - Constructor for class io.grpc.lb.v1.LoadBalancerGrpc.LoadBalancerStub
- loadBalanceToken_ - Variable in class io.grpc.lb.v1.ClientStatsPerToken.Builder
- loadBalanceToken_ - Variable in class io.grpc.lb.v1.ClientStatsPerToken
- loadBalanceToken_ - Variable in class io.grpc.lb.v1.Server.Builder
- loadBalanceToken_ - Variable in class io.grpc.lb.v1.Server
- loadBalancingConfig - Variable in class io.grpc.internal.ManagedChannelServiceConfig
- loadBalancingPolicyConfig - Variable in class io.grpc.LoadBalancer.ResolvedAddresses.Builder
- loadBalancingPolicyConfig - Variable in class io.grpc.LoadBalancer.ResolvedAddresses
- LoadFilePathExecution(File) - Constructor for class io.grpc.util.AdvancedTlsX509TrustManager.LoadFilePathExecution
- LoadFilePathExecution(File, File) - Constructor for class io.grpc.util.AdvancedTlsX509KeyManager.LoadFilePathExecution
- loadRecorder - Variable in class io.grpc.grpclb.GrpclbState.DropEntry
- loadRecorder - Variable in class io.grpc.grpclb.GrpclbState.LbStream
- LoadReportingTask(GrpclbState.LbStream) - Constructor for class io.grpc.grpclb.GrpclbState.LoadReportingTask
- loadReportIntervalMillis - Variable in class io.grpc.grpclb.GrpclbState.LbStream
- loadReportTimer - Variable in class io.grpc.grpclb.GrpclbState.LbStream
- loadServices(List<? extends BindableService>) - Static method in class io.grpc.servlet.GrpcServlet
- loadServices(List<? extends BindableService>) - Static method in class io.grpc.servlet.jakarta.GrpcServlet
- loadTrustBundleFromFile(String) - Static method in class io.grpc.internal.SpiffeUtil
-
Loads a SPIFFE trust bundle from a file, parsing it from the JSON format.
- local - Variable in class io.grpc.InternalChannelz.SocketStats
- local - Variable in class io.grpc.netty.Utils.FlowControlReader
- local_ - Variable in class io.grpc.channelz.v1.Socket.Builder
- local_ - Variable in class io.grpc.channelz.v1.Socket
- LOCAL_CERTIFICATE_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.Security.Tls
- LOCAL_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.Socket
- LOCAL_FLOW_CONTROL_WINDOW_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.SocketData
- localBuilder_ - Variable in class io.grpc.channelz.v1.Socket.Builder
- localBytes - Variable in class io.grpc.internal.TransportTracer.FlowControlWindows
- localCert - Variable in class io.grpc.InternalChannelz.Tls
- localCertificate_ - Variable in class io.grpc.channelz.v1.Security.Tls.Builder
- localCertificate_ - Variable in class io.grpc.channelz.v1.Security.Tls
- localContext - Static variable in class io.grpc.ThreadLocalContextStorage
-
Currently bound context.
- localFlowControlWindow - Variable in class io.grpc.InternalChannelz.TransportStats
- localFlowControlWindow_ - Variable in class io.grpc.channelz.v1.SocketData.Builder
- localFlowControlWindow_ - Variable in class io.grpc.channelz.v1.SocketData
- localFlowControlWindowBuilder_ - Variable in class io.grpc.channelz.v1.SocketData.Builder
- localHostname - Static variable in class io.grpc.internal.DnsNameResolver
-
Access through
DnsNameResolver.getLocalHostname()
. - localOnlyTransparentRetries - Variable in class io.grpc.internal.RetriableStream
- localSocketPicker - Variable in class io.grpc.netty.NettyChannelBuilder
- localSocketPicker - Variable in class io.grpc.netty.NettyChannelBuilder.NettyTransportFactory
- localSocketPicker - Variable in class io.grpc.netty.NettyClientTransport
- localSocketPicker(NettyChannelBuilder.LocalSocketPicker) - Method in class io.grpc.netty.NettyChannelBuilder
-
If non-
null
, attempts to create connections bound to a local port. - LocalSocketPicker() - Constructor for class io.grpc.netty.NettyChannelBuilder.LocalSocketPicker
- lock - Variable in class io.grpc.internal.ChannelTracer
- lock - Variable in class io.grpc.internal.DelayedClientTransport
- lock - Variable in class io.grpc.internal.ManagedChannelImpl.UncommittedRetriableStreamsRegistry
- lock - Variable in class io.grpc.internal.MetadataApplierImpl
- lock - Variable in class io.grpc.internal.MigratingThreadDeframer
- lock - Variable in class io.grpc.internal.RetriableStream.FutureCanceller
- lock - Variable in class io.grpc.internal.RetriableStream
-
Must be held when updating state, accessing state.buffer, or certain substream attributes.
- lock - Variable in class io.grpc.internal.ServerImpl
- lock - Variable in class io.grpc.MetricInstrumentRegistry
- lock - Variable in class io.grpc.protobuf.services.ProtoReflectionServiceV1
- lock - Variable in class io.grpc.rls.CachingRlsLbClient
- log - Static variable in class io.grpc.Context
- log - Static variable in class io.grpc.inprocess.InProcessTransport
- log - Static variable in class io.grpc.internal.AbstractClientStream
- log - Static variable in class io.grpc.internal.AtomicBackoff
- log - Static variable in class io.grpc.internal.ClientCallImpl
- log - Static variable in class io.grpc.internal.GrpcUtil
- log - Static variable in class io.grpc.internal.Http2Ping
- log - Static variable in class io.grpc.internal.LogExceptionRunnable
- log - Static variable in class io.grpc.internal.ManagedChannelImplBuilder
- log - Static variable in class io.grpc.internal.OobChannel
- log - Static variable in class io.grpc.internal.PickFirstLeafLoadBalancer
- log - Static variable in class io.grpc.internal.ProxyDetectorImpl
- log - Static variable in class io.grpc.internal.SerializeReentrantCallsDirectExecutor
- log - Static variable in class io.grpc.internal.SerializingExecutor
- log - Static variable in class io.grpc.internal.ServerCallImpl
- log - Static variable in class io.grpc.internal.ServerImpl
- log - Static variable in class io.grpc.internal.ServerImplBuilder
- log - Static variable in class io.grpc.InternalChannelz
- log - Static variable in class io.grpc.netty.NettyServer
- log - Static variable in class io.grpc.netty.NettyServerHandler.ServerChannelLogger
- log - Static variable in class io.grpc.netty.NettyServerStream
- log - Static variable in class io.grpc.netty.ProtocolNegotiators
- log - Variable in class io.grpc.servlet.AsyncServletOutputStreamWriter
- log - Variable in class io.grpc.servlet.jakarta.AsyncServletOutputStreamWriter
- log - Static variable in class io.grpc.stub.ClientCalls.ThreadlessExecutor
- log - Static variable in class io.grpc.ThreadLocalContextStorage
- log - Static variable in class io.grpc.util.AdvancedTlsX509KeyManager
- log - Static variable in class io.grpc.util.AdvancedTlsX509TrustManager
- log(ChannelLogger.ChannelLogLevel, String) - Method in class io.grpc.ChannelLogger
-
Logs a message.
- log(ChannelLogger.ChannelLogLevel, String) - Method in class io.grpc.internal.ChannelLoggerImpl
- log(ChannelLogger.ChannelLogLevel, String) - Method in class io.grpc.internal.InternalSubchannel.TransportLogger
- log(ChannelLogger.ChannelLogLevel, String) - Method in class io.grpc.netty.NettyServerHandler.ServerChannelLogger
- log(ChannelLogger.ChannelLogLevel, String, Object...) - Method in class io.grpc.ChannelLogger
-
Logs a message, using a message format and a list of arguments used to generate the log message with
MessageFormat
. - log(ChannelLogger.ChannelLogLevel, String, Object...) - Method in class io.grpc.internal.ChannelLoggerImpl
- log(ChannelLogger.ChannelLogLevel, String, Object...) - Method in class io.grpc.internal.InternalSubchannel.TransportLogger
- log(ChannelLogger.ChannelLogLevel, String, Object...) - Method in class io.grpc.netty.NettyServerHandler.ServerChannelLogger
- logCancel(long, GrpcLogEntry.Logger, long) - Method in class io.grpc.protobuf.services.BinlogHelper.SinkWriter
-
Logs the cancellation.
- logCancel(long, GrpcLogEntry.Logger, long) - Method in class io.grpc.protobuf.services.BinlogHelper.SinkWriterImpl
- logClientHeader(long, String, String, Duration, Metadata, GrpcLogEntry.Logger, long, SocketAddress) - Method in class io.grpc.protobuf.services.BinlogHelper.SinkWriter
-
Logs the client header.
- logClientHeader(long, String, String, Duration, Metadata, GrpcLogEntry.Logger, long, SocketAddress) - Method in class io.grpc.protobuf.services.BinlogHelper.SinkWriterImpl
- LogExceptionRunnable - Class in io.grpc.internal
-
A simple wrapper for a
Runnable
that logs any exception thrown by it, before re-throwing it. - LogExceptionRunnable(Runnable) - Constructor for class io.grpc.internal.LogExceptionRunnable
- logger - Static variable in class io.grpc.grpclb.GrpclbNameResolver
- logger - Variable in class io.grpc.grpclb.GrpclbState
- logger - Static variable in class io.grpc.internal.BackoffPolicyRetryScheduler
- logger - Static variable in class io.grpc.internal.ChannelTracer
- logger - Static variable in class io.grpc.internal.DelayedClientCall
- logger - Static variable in class io.grpc.internal.DnsNameResolver
- logger - Static variable in class io.grpc.internal.JndiResourceResolverFactory.JndiResourceResolver
- logger - Static variable in class io.grpc.internal.JsonParser
- logger - Static variable in class io.grpc.internal.ManagedChannelImpl
- logger - Static variable in class io.grpc.internal.ManagedChannelOrphanWrapper
- logger - Static variable in class io.grpc.internal.ReflectionLongAdderCounter
- logger - Static variable in class io.grpc.internal.TransportFrameUtil
- logger - Static variable in class io.grpc.LoadBalancerRegistry
- logger - Static variable in class io.grpc.ManagedChannelRegistry
- logger - Static variable in class io.grpc.Metadata
- logger - Static variable in class io.grpc.NameResolverRegistry
- logger - Static variable in class io.grpc.netty.GrpcSslContexts
- logger - Static variable in class io.grpc.netty.Http2ControlFrameLimitEncoder
- logger - Static variable in class io.grpc.netty.NettyClientHandler
- logger - Static variable in class io.grpc.netty.NettyServerHandler
- logger - Static variable in class io.grpc.netty.Utils
- logger - Static variable in class io.grpc.netty.WriteBufferingAndExceptionHandler
- logger - Static variable in class io.grpc.protobuf.services.BinlogHelper
- logger - Static variable in class io.grpc.protobuf.services.ChannelzProtoUtil
- logger - Static variable in class io.grpc.protobuf.services.HealthCheckingLoadBalancerFactory
- logger - Static variable in class io.grpc.protobuf.services.HealthServiceImpl
- logger - Static variable in class io.grpc.protobuf.services.TempFileSink
- logger - Variable in class io.grpc.rls.CachingRlsLbClient
- logger - Variable in class io.grpc.rls.RlsLoadBalancer
- logger - Static variable in class io.grpc.ServerRegistry
- logger - Static variable in class io.grpc.services.AdminInterface
- logger - Static variable in class io.grpc.servlet.jakarta.ServletAdapter
- logger - Static variable in class io.grpc.servlet.jakarta.ServletServerStream
- logger - Static variable in class io.grpc.servlet.ServletAdapter
- logger - Static variable in class io.grpc.servlet.ServletServerStream
- logger - Static variable in class io.grpc.stub.ClientCalls
- logger - Static variable in class io.grpc.util.MultiChildLoadBalancer
- logger - Variable in class io.grpc.util.OutlierDetectionLoadBalancer.DetectionTimer
- logger - Variable in class io.grpc.util.OutlierDetectionLoadBalancer.FailurePercentageOutlierEjectionAlgorithm
- logger - Variable in class io.grpc.util.OutlierDetectionLoadBalancer
- logger - Variable in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionSubchannel
- logger - Variable in class io.grpc.util.OutlierDetectionLoadBalancer.SuccessRateOutlierEjectionAlgorithm
- Logger(int) - Constructor for enum io.grpc.binarylog.v1.GrpcLogEntry.Logger
- logger_ - Variable in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
- logger_ - Variable in class io.grpc.binarylog.v1.GrpcLogEntry
- LOGGER_CLIENT - Enum constant in enum io.grpc.binarylog.v1.GrpcLogEntry.Logger
-
LOGGER_CLIENT = 1;
- LOGGER_CLIENT_VALUE - Static variable in enum io.grpc.binarylog.v1.GrpcLogEntry.Logger
-
LOGGER_CLIENT = 1;
- LOGGER_FIELD_NUMBER - Static variable in class io.grpc.binarylog.v1.GrpcLogEntry
- LOGGER_SERVER - Enum constant in enum io.grpc.binarylog.v1.GrpcLogEntry.Logger
-
LOGGER_SERVER = 2;
- LOGGER_SERVER_VALUE - Static variable in enum io.grpc.binarylog.v1.GrpcLogEntry.Logger
-
LOGGER_SERVER = 2;
- LOGGER_UNKNOWN - Enum constant in enum io.grpc.binarylog.v1.GrpcLogEntry.Logger
-
LOGGER_UNKNOWN = 0;
- LOGGER_UNKNOWN_VALUE - Static variable in enum io.grpc.binarylog.v1.GrpcLogEntry.Logger
-
LOGGER_UNKNOWN = 0;
- logHalfClose(long, GrpcLogEntry.Logger, long) - Method in class io.grpc.protobuf.services.BinlogHelper.SinkWriter
- logHalfClose(long, GrpcLogEntry.Logger, long) - Method in class io.grpc.protobuf.services.BinlogHelper.SinkWriterImpl
- logId - Variable in class io.grpc.inprocess.InProcessTransport
- logId - Variable in class io.grpc.internal.ChannelTracer
- logId - Variable in class io.grpc.internal.DelayedClientTransport
- logId - Variable in class io.grpc.internal.InternalSubchannel
- logId - Variable in class io.grpc.internal.InternalSubchannel.TransportLogger
- logId - Variable in class io.grpc.internal.ManagedChannelImpl
- logId - Variable in class io.grpc.internal.OobChannel
- logId - Variable in class io.grpc.internal.ServerImpl
- logId - Variable in class io.grpc.netty.NettyClientTransport
- logId - Variable in class io.grpc.netty.NettyServer
- logId - Variable in class io.grpc.netty.NettyServerTransport
- logId - Variable in class io.grpc.servlet.jakarta.ServletAdapter.GrpcAsyncListener
- logId - Variable in class io.grpc.servlet.jakarta.ServletAdapter.GrpcReadListener
- logId - Variable in class io.grpc.servlet.jakarta.ServletServerBuilder.ServerTransportImpl
- logId - Variable in class io.grpc.servlet.jakarta.ServletServerStream
- logId - Variable in class io.grpc.servlet.ServletAdapter.GrpcAsyncListener
- logId - Variable in class io.grpc.servlet.ServletAdapter.GrpcReadListener
- logId - Variable in class io.grpc.servlet.ServletServerBuilder.ServerTransportImpl
- logId - Variable in class io.grpc.servlet.ServletServerStream
- logOnly(InternalLogId, ChannelLogger.ChannelLogLevel, String) - Static method in class io.grpc.internal.ChannelLoggerImpl
- logOnly(InternalLogId, ChannelLogger.ChannelLogLevel, String, Object...) - Static method in class io.grpc.internal.ChannelLoggerImpl
- logOnly(InternalLogId, Level, String) - Static method in class io.grpc.internal.ChannelTracer
- logRpcMessage(long, GrpcLogEntry.EventType, MethodDescriptor.Marshaller<T>, T, GrpcLogEntry.Logger, long) - Method in class io.grpc.protobuf.services.BinlogHelper.SinkWriter
-
Logs the message message.
- logRpcMessage(long, GrpcLogEntry.EventType, MethodDescriptor.Marshaller<T>, T, GrpcLogEntry.Logger, long) - Method in class io.grpc.protobuf.services.BinlogHelper.SinkWriterImpl
- logServerHeader(long, Metadata, GrpcLogEntry.Logger, long, SocketAddress) - Method in class io.grpc.protobuf.services.BinlogHelper.SinkWriter
-
Logs the server header.
- logServerHeader(long, Metadata, GrpcLogEntry.Logger, long, SocketAddress) - Method in class io.grpc.protobuf.services.BinlogHelper.SinkWriterImpl
- logSslEngineDetails(Level, ChannelHandlerContext, String, Throwable) - Static method in class io.grpc.netty.ProtocolNegotiators
- logTrailer(long, Status, Metadata, GrpcLogEntry.Logger, long, SocketAddress) - Method in class io.grpc.protobuf.services.BinlogHelper.SinkWriter
-
Logs the server trailer.
- logTrailer(long, Status, Metadata, GrpcLogEntry.Logger, long, SocketAddress) - Method in class io.grpc.protobuf.services.BinlogHelper.SinkWriterImpl
- LongCounter - Interface in io.grpc.internal
-
An interface for a long base counter.
- LongCounterFactory - Class in io.grpc.internal
-
A factory for creating
LongCounter
objects. - LongCounterFactory() - Constructor for class io.grpc.internal.LongCounterFactory
- LongCounterMetricInstrument - Class in io.grpc
-
Represents a long-valued counter metric instrument.
- LongCounterMetricInstrument(int, String, String, String, List<String>, List<String>, boolean) - Constructor for class io.grpc.LongCounterMetricInstrument
- LongGaugeMetricInstrument - Class in io.grpc
-
Represents a long-valued gauge metric instrument.
- LongGaugeMetricInstrument(int, String, String, String, List<String>, List<String>, boolean) - Constructor for class io.grpc.LongGaugeMetricInstrument
- LongHistogramMetricInstrument - Class in io.grpc
-
Represents a long-valued histogram metric instrument.
- LongHistogramMetricInstrument(int, String, String, String, List<Long>, List<String>, List<String>, boolean) - Constructor for class io.grpc.LongHistogramMetricInstrument
- LongHolder() - Constructor for class io.grpc.grpclb.GrpclbClientLoadRecorder.LongHolder
- LOOKUP_SERVICE_FIELD_NUMBER - Static variable in class io.grpc.lookup.v1.RouteLookupConfig
- LOOKUP_SERVICE_TIMEOUT_FIELD_NUMBER - Static variable in class io.grpc.lookup.v1.RouteLookupConfig
- lookupCompressor(String) - Method in class io.grpc.CompressorRegistry
- lookupDecompressor(String) - Method in class io.grpc.DecompressorRegistry
-
Returns a decompressor for the given message encoding, or
null
if none has been registered. - lookupMethod(String) - Method in class io.grpc.HandlerRegistry
-
Lookup a
ServerMethodDefinition
by its fully-qualified name. - lookupMethod(String, String) - Method in class io.grpc.HandlerRegistry
-
Lookup a
ServerMethodDefinition
by its fully-qualified name. - lookupMethod(String, String) - Method in class io.grpc.internal.InternalHandlerRegistry
- lookupMethod(String, String) - Method in class io.grpc.internal.ServerImplBuilder.DefaultFallbackRegistry
- lookupMethod(String, String) - Method in class io.grpc.util.MutableHandlerRegistry
-
Note: This does not actually honor the authority provided.
- lookupService - Variable in class io.grpc.rls.AutoValue_RlsProtoData_RouteLookupConfig.Builder
- lookupService - Variable in class io.grpc.rls.AutoValue_RlsProtoData_RouteLookupConfig
- lookupService - Variable in class io.grpc.rls.CachingRlsLbClient.RlsPicker
- lookupService() - Method in class io.grpc.rls.AutoValue_RlsProtoData_RouteLookupConfig
- lookupService() - Method in class io.grpc.rls.RlsProtoData.RouteLookupConfig
-
Returns the name of the lookup service as a gRPC URI.
- lookupService(String) - Method in class io.grpc.rls.AutoValue_RlsProtoData_RouteLookupConfig.Builder
- lookupService(String) - Method in class io.grpc.rls.RlsProtoData.RouteLookupConfig.Builder
- lookupService_ - Variable in class io.grpc.lookup.v1.RouteLookupConfig.Builder
- lookupService_ - Variable in class io.grpc.lookup.v1.RouteLookupConfig
- lookUpServiceConfig - Variable in class io.grpc.internal.ManagedChannelImpl
- lookUpServiceConfig - Variable in class io.grpc.internal.ManagedChannelImplBuilder
- lookUpServiceConfig - Variable in class io.grpc.internal.ServiceConfigState
- lookupServiceTimeout_ - Variable in class io.grpc.lookup.v1.RouteLookupConfig.Builder
- lookupServiceTimeout_ - Variable in class io.grpc.lookup.v1.RouteLookupConfig
- lookupServiceTimeoutBuilder_ - Variable in class io.grpc.lookup.v1.RouteLookupConfig.Builder
- lookupServiceTimeoutInNanos - Variable in class io.grpc.rls.AutoValue_RlsProtoData_RouteLookupConfig.Builder
- lookupServiceTimeoutInNanos - Variable in class io.grpc.rls.AutoValue_RlsProtoData_RouteLookupConfig
- lookupServiceTimeoutInNanos() - Method in class io.grpc.rls.AutoValue_RlsProtoData_RouteLookupConfig
- lookupServiceTimeoutInNanos() - Method in class io.grpc.rls.RlsProtoData.RouteLookupConfig
-
Returns the timeout value for lookup service requests.
- lookupServiceTimeoutInNanos(long) - Method in class io.grpc.rls.AutoValue_RlsProtoData_RouteLookupConfig.Builder
- lookupServiceTimeoutInNanos(long) - Method in class io.grpc.rls.RlsProtoData.RouteLookupConfig.Builder
- lost - Variable in class io.grpc.InternalChannelz.TcpInfo.Builder
- lost - Variable in class io.grpc.InternalChannelz.TcpInfo
- LruCache<K,
V> - Interface in io.grpc.rls -
An LruCache is a cache with least recently used eviction.
- LruCache.EvictionListener<K,
V> - Interface in io.grpc.rls -
A Listener notifies cache eviction events.
- LruCache.EvictionType - Enum in io.grpc.rls
-
Type of cache eviction.
M
- makeHedgingDecision(Status, Metadata) - Method in class io.grpc.internal.RetriableStream.Sublistener
- makeRetryDecision(Status, Metadata) - Method in class io.grpc.internal.RetriableStream.Sublistener
-
Decides in current situation whether or not the RPC should retry and if it should retry how long the backoff should be.
- makeTargetStringForDirectAddress(SocketAddress) - Static method in class io.grpc.internal.ManagedChannelImplBuilder
-
Returns a target string for the SocketAddress.
- ManagedChannel - Class in io.grpc
-
A
Channel
that provides lifecycle management. - ManagedChannel() - Constructor for class io.grpc.ManagedChannel
- ManagedChannelBuilder<T> - Class in io.grpc
-
A builder for
ManagedChannel
instances. - ManagedChannelBuilder() - Constructor for class io.grpc.ManagedChannelBuilder
- ManagedChannelBuilder.InterceptorFactory - Interface in io.grpc
-
Internal-only.
- ManagedChannelDefaultPortProvider() - Constructor for class io.grpc.internal.ManagedChannelImplBuilder.ManagedChannelDefaultPortProvider
- ManagedChannelImpl - Class in io.grpc.internal
-
A communication channel for making outgoing RPCs.
- ManagedChannelImpl(ManagedChannelImplBuilder, ClientTransportFactory, URI, NameResolverProvider, BackoffPolicy.Provider, ObjectPool<? extends Executor>, Supplier<Stopwatch>, List<ClientInterceptor>, TimeProvider) - Constructor for class io.grpc.internal.ManagedChannelImpl
- ManagedChannelImpl.ChannelStreamProvider - Class in io.grpc.internal
- ManagedChannelImpl.ConfigSelectingClientCall<ReqT,
RespT> - Class in io.grpc.internal -
A client call for a given channel that applies a given config selector when it starts.
- ManagedChannelImpl.DelayedTransportListener - Class in io.grpc.internal
-
Called from syncContext.
- ManagedChannelImpl.ExecutorHolder - Class in io.grpc.internal
-
Lazily request for Executor from an executor pool.
- ManagedChannelImpl.IdleModeStateAggregator - Class in io.grpc.internal
-
Must be accessed from syncContext.
- ManagedChannelImpl.IdleModeTimer - Class in io.grpc.internal
- ManagedChannelImpl.LbHelperImpl - Class in io.grpc.internal
- ManagedChannelImpl.LbHelperImpl.DefaultChannelCreds - Class in io.grpc.internal
-
A placeholder for channel creds if user did not specify channel creds for the channel.
- ManagedChannelImpl.NameResolverListener - Class in io.grpc.internal
- ManagedChannelImpl.RealChannel - Class in io.grpc.internal
- ManagedChannelImpl.RealChannel.PendingCall<ReqT,
RespT> - Class in io.grpc.internal - ManagedChannelImpl.RealChannel.PendingCall.PendingCallRemoval - Class in io.grpc.internal
- ManagedChannelImpl.ResolutionState - Enum in io.grpc.internal
-
A ResolutionState indicates the status of last name resolution.
- ManagedChannelImpl.RestrictedScheduledExecutor - Class in io.grpc.internal
- ManagedChannelImpl.SubchannelImpl - Class in io.grpc.internal
- ManagedChannelImpl.UncommittedRetriableStreamsRegistry - Class in io.grpc.internal
-
A registry that prevents channel shutdown from killing existing retry attempts that are in backoff.
- managedChannelImplBuilder - Variable in class io.grpc.inprocess.InProcessChannelBuilder
- managedChannelImplBuilder - Variable in class io.grpc.netty.NettyChannelBuilder
- ManagedChannelImplBuilder - Class in io.grpc.internal
-
Default managed channel builder, for usage in Transport implementations.
- ManagedChannelImplBuilder(String, ChannelCredentials, CallCredentials, ManagedChannelImplBuilder.ClientTransportFactoryBuilder, ManagedChannelImplBuilder.ChannelBuilderDefaultPortProvider) - Constructor for class io.grpc.internal.ManagedChannelImplBuilder
-
Creates a new managed channel builder with a target string, which can be either a valid
NameResolver
-compliant URI, or an authority string. - ManagedChannelImplBuilder(String, ManagedChannelImplBuilder.ClientTransportFactoryBuilder, ManagedChannelImplBuilder.ChannelBuilderDefaultPortProvider) - Constructor for class io.grpc.internal.ManagedChannelImplBuilder
-
Creates a new managed channel builder with a target string, which can be either a valid
NameResolver
-compliant URI, or an authority string. - ManagedChannelImplBuilder(SocketAddress, String, ChannelCredentials, CallCredentials, ManagedChannelImplBuilder.ClientTransportFactoryBuilder, ManagedChannelImplBuilder.ChannelBuilderDefaultPortProvider) - Constructor for class io.grpc.internal.ManagedChannelImplBuilder
-
Creates a new managed channel builder with the given server address, authority string of the channel.
- ManagedChannelImplBuilder(SocketAddress, String, ManagedChannelImplBuilder.ClientTransportFactoryBuilder, ManagedChannelImplBuilder.ChannelBuilderDefaultPortProvider) - Constructor for class io.grpc.internal.ManagedChannelImplBuilder
-
Creates a new managed channel builder with the given server address, authority string of the channel.
- ManagedChannelImplBuilder.ChannelBuilderDefaultPortProvider - Interface in io.grpc.internal
-
An interface for Transport implementors to provide a default port to
NameResolver
for use in cases where the target string doesn't include a port. - ManagedChannelImplBuilder.ClientTransportFactoryBuilder - Interface in io.grpc.internal
-
An interface for Transport implementors to provide the
ClientTransportFactory
appropriate for the channel. - ManagedChannelImplBuilder.DirectAddressNameResolverProvider - Class in io.grpc.internal
- ManagedChannelImplBuilder.FixedPortProvider - Class in io.grpc.internal
-
Default implementation of
ManagedChannelImplBuilder.ChannelBuilderDefaultPortProvider
that returns a fixed port. - ManagedChannelImplBuilder.InterceptorFactoryWrapper - Class in io.grpc.internal
- ManagedChannelImplBuilder.ManagedChannelDefaultPortProvider - Class in io.grpc.internal
- ManagedChannelImplBuilder.ResolvedNameResolver - Class in io.grpc.internal
- ManagedChannelImplBuilder.UnsupportedClientTransportFactoryBuilder - Class in io.grpc.internal
-
Convenience ClientTransportFactoryBuilder, throws UnsupportedOperationException().
- ManagedChannelOrphanWrapper - Class in io.grpc.internal
-
Best effort detecting channels that has not been properly cleaned up.
- ManagedChannelOrphanWrapper(ManagedChannel) - Constructor for class io.grpc.internal.ManagedChannelOrphanWrapper
- ManagedChannelOrphanWrapper(ManagedChannel, ReferenceQueue<ManagedChannelOrphanWrapper>, ConcurrentMap<ManagedChannelOrphanWrapper.ManagedChannelReference, ManagedChannelOrphanWrapper.ManagedChannelReference>) - Constructor for class io.grpc.internal.ManagedChannelOrphanWrapper
- ManagedChannelOrphanWrapper.ManagedChannelReference - Class in io.grpc.internal
- ManagedChannelPriorityAccessor() - Constructor for class io.grpc.ManagedChannelRegistry.ManagedChannelPriorityAccessor
- ManagedChannelProvider - Class in io.grpc
-
Provider of managed channels for transport agnostic consumption.
- ManagedChannelProvider() - Constructor for class io.grpc.ManagedChannelProvider
- ManagedChannelProvider.NewChannelBuilderResult - Class in io.grpc
- ManagedChannelProvider.ProviderNotFoundException - Exception Class in io.grpc
-
Thrown when no suitable
ManagedChannelProvider
objects can be found. - ManagedChannelReference(ManagedChannelOrphanWrapper, ManagedChannel, ReferenceQueue<ManagedChannelOrphanWrapper>, ConcurrentMap<ManagedChannelOrphanWrapper.ManagedChannelReference, ManagedChannelOrphanWrapper.ManagedChannelReference>) - Constructor for class io.grpc.internal.ManagedChannelOrphanWrapper.ManagedChannelReference
- ManagedChannelRegistry - Class in io.grpc
-
Registry of
ManagedChannelProvider
s. - ManagedChannelRegistry() - Constructor for class io.grpc.ManagedChannelRegistry
- ManagedChannelRegistry.ManagedChannelPriorityAccessor - Class in io.grpc
- ManagedChannelRegistry.ProviderNotFoundException - Exception Class in io.grpc
-
Thrown when no suitable
ManagedChannelProvider
objects can be found. - ManagedChannelServiceConfig - Class in io.grpc.internal
-
ManagedChannelServiceConfig
is a fully parsed and validated representation of service configuration data. - ManagedChannelServiceConfig(ManagedChannelServiceConfig.MethodInfo, Map<String, ManagedChannelServiceConfig.MethodInfo>, Map<String, ManagedChannelServiceConfig.MethodInfo>, RetriableStream.Throttle, Object, Map<String, ?>) - Constructor for class io.grpc.internal.ManagedChannelServiceConfig
- ManagedChannelServiceConfig.MethodInfo - Class in io.grpc.internal
-
Equivalent of MethodConfig from a ServiceConfig with restrictions from Channel setting.
- ManagedChannelServiceConfig.ServiceConfigConvertedSelector - Class in io.grpc.internal
- ManagedClientTransport - Interface in io.grpc.internal
-
A
ClientTransport
that has life-cycle management. - ManagedClientTransport.Listener - Interface in io.grpc.internal
-
Receives notifications for the transport life-cycle events.
- ManagedRunnable(Runnable) - Constructor for class io.grpc.SynchronizationContext.ManagedRunnable
- mark - Variable in class io.grpc.internal.MessageDeframer.SizeEnforcingInputStream
- mark - Variable in class io.grpc.internal.ReadableBuffers.ByteArrayWrapper
- mark() - Method in class io.grpc.internal.AbstractReadableBuffer
- mark() - Method in class io.grpc.internal.CompositeReadableBuffer
- mark() - Method in class io.grpc.internal.ForwardingReadableBuffer
- mark() - Method in interface io.grpc.internal.ReadableBuffer
-
Marks the current position in this buffer.
- mark() - Method in class io.grpc.internal.ReadableBuffers.ByteArrayWrapper
- mark() - Method in class io.grpc.internal.ReadableBuffers.ByteReadableBufferWrapper
- mark() - Method in class io.grpc.netty.NettyReadableBuffer
- mark(int) - Method in class io.grpc.internal.MessageDeframer.SizeEnforcingInputStream
- mark(int) - Method in class io.grpc.internal.ReadableBuffers.BufferInputStream
- markCancelled() - Method in class io.grpc.internal.RetriableStream.FutureCanceller
- marked - Variable in class io.grpc.internal.CompositeReadableBuffer
- markSupported() - Method in class io.grpc.internal.AbstractReadableBuffer
- markSupported() - Method in class io.grpc.internal.CompositeReadableBuffer
- markSupported() - Method in class io.grpc.internal.ForwardingReadableBuffer
- markSupported() - Method in interface io.grpc.internal.ReadableBuffer
-
Indicates whether or not
ReadableBuffer.mark()
operation is supported for this buffer. - markSupported() - Method in class io.grpc.internal.ReadableBuffers.BufferInputStream
- markSupported() - Method in class io.grpc.internal.ReadableBuffers.ByteArrayWrapper
- markSupported() - Method in class io.grpc.internal.ReadableBuffers.ByteReadableBufferWrapper
- markSupported() - Method in class io.grpc.netty.NettyReadableBuffer
- marshaller - Variable in class io.grpc.Metadata.AsciiKey
- marshaller - Variable in class io.grpc.Metadata.BinaryKey
- marshaller - Variable in class io.grpc.Metadata.Key
- marshaller - Variable in class io.grpc.Metadata.LazyStreamBinaryKey
- marshaller - Variable in class io.grpc.Metadata.LazyValue
- marshaller - Variable in class io.grpc.Metadata.TrustedAsciiKey
- marshaller(T) - Static method in class io.grpc.protobuf.lite.ProtoLiteUtils
-
Creates a
MethodDescriptor.Marshaller
for protos of the same type asdefaultInstance
. - marshaller(T) - Static method in class io.grpc.protobuf.ProtoUtils
-
Create a
MethodDescriptor.Marshaller
for protos of the same type asdefaultInstance
. - marshallerWithRecursionLimit(T, int) - Static method in class io.grpc.protobuf.lite.ProtoLiteUtils
-
Creates a
MethodDescriptor.Marshaller
for protos of the same type asdefaultInstance
and a custom limit for the recursion depth. - marshallerWithRecursionLimit(T, int) - Static method in class io.grpc.protobuf.ProtoUtils
-
Creates a
MethodDescriptor.Marshaller
for protos of the same type asdefaultInstance
and a custom limit for the recursion depth. - masterListener - Variable in class io.grpc.internal.RetriableStream
- MAX_AGE_FIELD_NUMBER - Static variable in class io.grpc.lookup.v1.RouteLookupConfig
- MAX_AGE_NANOS - Static variable in class io.grpc.rls.RlsProtoConverters
- MAX_BACKOFF - Static variable in class io.grpc.netty.AbstractNettyHandler.FlowControlPinger
- MAX_BUFFER - Static variable in class io.grpc.netty.NettyWritableBufferAllocator
- MAX_BUFFER_LENGTH - Static variable in class io.grpc.protobuf.services.BinaryLogProvider.IoUtils
-
maximum buffer to be read is 16 KB.
- MAX_BUFFER_SIZE - Static variable in class io.grpc.internal.MessageDeframer
- MAX_CACHE_SIZE - Static variable in class io.grpc.rls.RlsProtoConverters
- MAX_CONNECTION_AGE_GRACE_NANOS_INFINITE - Static variable in class io.grpc.netty.NettyServerBuilder
- MAX_CONNECTION_AGE_NANOS_DISABLED - Static variable in class io.grpc.netty.NettyServerBuilder
- MAX_CONNECTION_IDLE_NANOS_DISABLED - Static variable in class io.grpc.netty.NettyServerBuilder
- MAX_OFFSET - Static variable in class io.grpc.Deadline
- MAX_PING_STRIKES - Static variable in class io.grpc.internal.KeepAliveEnforcer
- MAX_RESULTS_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.GetServerSocketsRequest
- MAX_RESULTS_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.GetServersRequest
- MAX_RESULTS_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.GetTopChannelsRequest
- MAX_RST_COUNT_DISABLED - Static variable in class io.grpc.netty.NettyServerBuilder
- MAX_WINDOW_SIZE - Static variable in class io.grpc.netty.AbstractNettyHandler.FlowControlPinger
- maxAge_ - Variable in class io.grpc.lookup.v1.RouteLookupConfig.Builder
- maxAge_ - Variable in class io.grpc.lookup.v1.RouteLookupConfig
- maxAgeBuilder_ - Variable in class io.grpc.lookup.v1.RouteLookupConfig.Builder
- maxAgeInNanos - Variable in class io.grpc.rls.AutoValue_RlsProtoData_RouteLookupConfig.Builder
- maxAgeInNanos - Variable in class io.grpc.rls.AutoValue_RlsProtoData_RouteLookupConfig
- maxAgeInNanos() - Method in class io.grpc.rls.AutoValue_RlsProtoData_RouteLookupConfig
- maxAgeInNanos() - Method in class io.grpc.rls.RlsProtoData.RouteLookupConfig
-
Returns the maximum age the result will be cached.
- maxAgeInNanos(long) - Method in class io.grpc.rls.AutoValue_RlsProtoData_RouteLookupConfig.Builder
- maxAgeInNanos(long) - Method in class io.grpc.rls.RlsProtoData.RouteLookupConfig.Builder
- maxAgeNanos - Variable in class io.grpc.rls.CachingRlsLbClient
- maxAttempts - Variable in class io.grpc.internal.HedgingPolicy
- maxAttempts - Variable in class io.grpc.internal.RetryPolicy
- maxBackoffNanos - Variable in class io.grpc.internal.ExponentialBackoffPolicy
- maxBackoffNanos - Variable in class io.grpc.internal.RetryPolicy
- maxConcurrentCallsPerConnection - Variable in class io.grpc.netty.NettyServerBuilder
- maxConcurrentCallsPerConnection(int) - Method in class io.grpc.netty.NettyServerBuilder
-
The maximum number of concurrent calls permitted for each incoming connection.
- maxConnectionAge(long, TimeUnit) - Method in class io.grpc.ForwardingServerBuilder
- maxConnectionAge(long, TimeUnit) - Method in class io.grpc.netty.NettyServerBuilder
-
Sets a custom max connection age, connection lasting longer than which will be gracefully terminated.
- maxConnectionAge(long, TimeUnit) - Method in class io.grpc.ServerBuilder
-
Sets the maximum connection age, connections lasting longer than which will be gracefully terminated.
- maxConnectionAgeGrace(long, TimeUnit) - Method in class io.grpc.ForwardingServerBuilder
- maxConnectionAgeGrace(long, TimeUnit) - Method in class io.grpc.netty.NettyServerBuilder
-
Sets a custom grace time for the graceful connection termination.
- maxConnectionAgeGrace(long, TimeUnit) - Method in class io.grpc.ServerBuilder
-
Sets the grace time for the graceful connection termination.
- maxConnectionAgeGraceInNanos - Variable in class io.grpc.netty.NettyServer
- maxConnectionAgeGraceInNanos - Variable in class io.grpc.netty.NettyServerBuilder
- maxConnectionAgeGraceInNanos - Variable in class io.grpc.netty.NettyServerHandler
- maxConnectionAgeGraceInNanos - Variable in class io.grpc.netty.NettyServerTransport
- maxConnectionAgeInNanos - Variable in class io.grpc.netty.NettyServer
- maxConnectionAgeInNanos - Variable in class io.grpc.netty.NettyServerBuilder
- maxConnectionAgeInNanos - Variable in class io.grpc.netty.NettyServerHandler
- maxConnectionAgeInNanos - Variable in class io.grpc.netty.NettyServerTransport
- maxConnectionAgeMonitor - Variable in class io.grpc.netty.NettyServerHandler
- maxConnectionIdle(long, TimeUnit) - Method in class io.grpc.ForwardingServerBuilder
- maxConnectionIdle(long, TimeUnit) - Method in class io.grpc.netty.NettyServerBuilder
-
Sets a custom max connection idle time, connection being idle for longer than which will be gracefully terminated.
- maxConnectionIdle(long, TimeUnit) - Method in class io.grpc.ServerBuilder
-
Sets the maximum connection idle time, connections being idle for longer than which will be gracefully terminated.
- maxConnectionIdleInNanos - Variable in class io.grpc.internal.MaxConnectionIdleManager
- maxConnectionIdleInNanos - Variable in class io.grpc.netty.NettyServer
- maxConnectionIdleInNanos - Variable in class io.grpc.netty.NettyServerBuilder
- maxConnectionIdleInNanos - Variable in class io.grpc.netty.NettyServerTransport
- maxConnectionIdleManager - Variable in class io.grpc.netty.NettyServerHandler
- MaxConnectionIdleManager - Class in io.grpc.internal
-
Monitors connection idle time; shutdowns the connection if the max connection idle is reached.
- MaxConnectionIdleManager(long) - Constructor for class io.grpc.internal.MaxConnectionIdleManager
- MaxConnectionIdleManager(long, MaxConnectionIdleManager.Ticker) - Constructor for class io.grpc.internal.MaxConnectionIdleManager
- MaxConnectionIdleManager.Ticker - Interface in io.grpc.internal
- maxCount - Variable in class io.grpc.internal.MessageDeframer.SizeEnforcingInputStream
- maxEjectionPercent - Variable in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig.Builder
- maxEjectionPercent - Variable in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig
- maxEjectionTimeElapsed(long) - Method in class io.grpc.util.OutlierDetectionLoadBalancer.EndpointTracker
- maxEjectionTimeNanos - Variable in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig.Builder
- maxEjectionTimeNanos - Variable in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig
- maxHeaderBytes - Variable in class io.grpc.protobuf.services.BinlogHelper.SinkWriterImpl
- maxHeaderListSize - Variable in class io.grpc.netty.NettyChannelBuilder
- maxHeaderListSize - Variable in class io.grpc.netty.NettyChannelBuilder.NettyTransportFactory
- maxHeaderListSize - Variable in class io.grpc.netty.NettyClientTransport
- maxHeaderListSize - Variable in class io.grpc.netty.NettyServer
- maxHeaderListSize - Variable in class io.grpc.netty.NettyServerBuilder
- maxHeaderListSize - Variable in class io.grpc.netty.NettyServerTransport
- maxHeaderListSize(int) - Method in class io.grpc.netty.NettyChannelBuilder
-
Deprecated.Use
NettyChannelBuilder.maxInboundMetadataSize(int)
instead - maxHeaderListSize(int) - Method in class io.grpc.netty.NettyServerBuilder
-
Deprecated.Use
NettyServerBuilder.maxInboundMetadataSize(int)
instead - maxHedgedAttempts - Variable in class io.grpc.internal.ManagedChannelImplBuilder
- maxHedgedAttempts(int) - Method in class io.grpc.ForwardingChannelBuilder
- maxHedgedAttempts(int) - Method in class io.grpc.ForwardingChannelBuilder2
- maxHedgedAttempts(int) - Method in class io.grpc.internal.ManagedChannelImplBuilder
- maxHedgedAttempts(int) - Method in class io.grpc.ManagedChannelBuilder
-
Sets the maximum number of hedged attempts that may be configured by the service config.
- maxHedgedAttemptsLimit - Variable in class io.grpc.internal.ScParser
- maxInboundMessageSize - Variable in class io.grpc.CallOptions.Builder
- maxInboundMessageSize - Variable in class io.grpc.CallOptions
- maxInboundMessageSize - Variable in class io.grpc.internal.ManagedChannelServiceConfig.MethodInfo
- maxInboundMessageSize - Variable in class io.grpc.internal.MessageDeframer
- maxInboundMessageSize - Variable in class io.grpc.netty.NettyChannelBuilder
- maxInboundMessageSize - Variable in class io.grpc.servlet.jakarta.ServletAdapter
- maxInboundMessageSize - Variable in class io.grpc.servlet.jakarta.ServletServerBuilder
- maxInboundMessageSize - Variable in class io.grpc.servlet.ServletAdapter
- maxInboundMessageSize - Variable in class io.grpc.servlet.ServletServerBuilder
- maxInboundMessageSize(int) - Method in class io.grpc.ForwardingChannelBuilder
- maxInboundMessageSize(int) - Method in class io.grpc.ForwardingChannelBuilder2
- maxInboundMessageSize(int) - Method in class io.grpc.ForwardingServerBuilder
- maxInboundMessageSize(int) - Method in class io.grpc.inprocess.InProcessChannelBuilder
- 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.netty.NettyChannelBuilder
-
Sets the maximum message size allowed for a single gRPC frame.
- maxInboundMessageSize(int) - Method in class io.grpc.netty.NettyServerBuilder
-
Sets the maximum message size allowed to be received on the server.
- maxInboundMessageSize(int) - Method in class io.grpc.ServerBuilder
-
Sets the maximum message size allowed to be received on the server.
- maxInboundMessageSize(int) - Method in class io.grpc.servlet.jakarta.ServletServerBuilder
- maxInboundMessageSize(int) - Method in class io.grpc.servlet.ServletServerBuilder
- maxInboundMetadataSize - Variable in class io.grpc.inprocess.InProcessChannelBuilder.InProcessClientTransportFactory
- maxInboundMetadataSize - Variable in class io.grpc.inprocess.InProcessChannelBuilder
- maxInboundMetadataSize - Variable in class io.grpc.inprocess.InProcessServer
- maxInboundMetadataSize - Variable in class io.grpc.inprocess.InProcessServerBuilder
- maxInboundMetadataSize(int) - Method in class io.grpc.ForwardingChannelBuilder
- maxInboundMetadataSize(int) - Method in class io.grpc.ForwardingChannelBuilder2
- maxInboundMetadataSize(int) - Method in class io.grpc.ForwardingServerBuilder
- maxInboundMetadataSize(int) - Method in class io.grpc.inprocess.InProcessChannelBuilder
-
Sets the maximum size of metadata allowed to be received.
- maxInboundMetadataSize(int) - Method in class io.grpc.inprocess.InProcessServerBuilder
-
Sets the maximum size of metadata allowed to be received.
- maxInboundMetadataSize(int) - Method in class io.grpc.ManagedChannelBuilder
-
Sets the maximum size of metadata allowed to be received.
- maxInboundMetadataSize(int) - Method in class io.grpc.netty.NettyChannelBuilder
-
Sets the maximum size of metadata allowed to be received.
- maxInboundMetadataSize(int) - Method in class io.grpc.netty.NettyServerBuilder
-
Sets the maximum size of metadata allowed to be received.
- maxInboundMetadataSize(int) - Method in class io.grpc.ServerBuilder
-
Sets the maximum size of metadata allowed to be received.
- maxMessageBytes - Variable in class io.grpc.protobuf.services.BinlogHelper.SinkWriterImpl
- maxMessageSize - Variable in class io.grpc.internal.MessageDeframer.SizeEnforcingInputStream
- maxMessageSize - Variable in class io.grpc.netty.NettyChannelBuilder.NettyTransportFactory
- maxMessageSize - Variable in class io.grpc.netty.NettyClientTransport
- maxMessageSize - Variable in class io.grpc.netty.NettyServer
- maxMessageSize - Variable in class io.grpc.netty.NettyServerBuilder
- maxMessageSize - Variable in class io.grpc.netty.NettyServerHandler
- maxMessageSize - Variable in class io.grpc.netty.NettyServerTransport
- maxMessageSize(int) - Method in class io.grpc.netty.NettyServerBuilder
-
Deprecated.Call
NettyServerBuilder.maxInboundMessageSize(int)
instead. This method will be removed in a future release. - maxOutboundMessageSize - Variable in class io.grpc.CallOptions.Builder
- maxOutboundMessageSize - Variable in class io.grpc.CallOptions
- maxOutboundMessageSize - Variable in class io.grpc.internal.ManagedChannelServiceConfig.MethodInfo
- maxOutboundMessageSize - Variable in class io.grpc.internal.MessageFramer
- maxOutstandingControlFrames - Variable in class io.grpc.netty.Http2ControlFrameLimitEncoder
- maxPageSize - Variable in class io.grpc.protobuf.services.ChannelzService
- maxResults_ - Variable in class io.grpc.channelz.v1.GetServerSocketsRequest.Builder
- maxResults_ - Variable in class io.grpc.channelz.v1.GetServerSocketsRequest
- maxResults_ - Variable in class io.grpc.channelz.v1.GetServersRequest.Builder
- maxResults_ - Variable in class io.grpc.channelz.v1.GetServersRequest
- maxResults_ - Variable in class io.grpc.channelz.v1.GetTopChannelsRequest.Builder
- maxResults_ - Variable in class io.grpc.channelz.v1.GetTopChannelsRequest
- maxRetryAttempts - Variable in class io.grpc.internal.ManagedChannelImplBuilder
- maxRetryAttempts(int) - Method in class io.grpc.ForwardingChannelBuilder
- maxRetryAttempts(int) - Method in class io.grpc.ForwardingChannelBuilder2
- maxRetryAttempts(int) - Method in class io.grpc.internal.ManagedChannelImplBuilder
- maxRetryAttempts(int) - Method in class io.grpc.ManagedChannelBuilder
-
Sets the maximum number of retry attempts that may be configured by the service config.
- maxRetryAttemptsLimit - Variable in class io.grpc.internal.ScParser
- maxRstCount - Variable in class io.grpc.netty.NettyServer
- maxRstCount - Variable in class io.grpc.netty.NettyServerBuilder
- maxRstCount - Variable in class io.grpc.netty.NettyServerHandler
- maxRstCount - Variable in class io.grpc.netty.NettyServerTransport
- maxRstFramesPerWindow(int, int) - Method in class io.grpc.netty.NettyServerBuilder
-
Limits the rate of incoming RST_STREAM frames per connection to maxRstStream per secondsPerWindow.
- maxRstPeriodNanos - Variable in class io.grpc.netty.NettyServer
- maxRstPeriodNanos - Variable in class io.grpc.netty.NettyServerBuilder
- maxRstPeriodNanos - Variable in class io.grpc.netty.NettyServerHandler
- maxRstPeriodNanos - Variable in class io.grpc.netty.NettyServerTransport
- maxStreams - Variable in class io.grpc.netty.NettyServerTransport
- maxStreamsPerConnection - Variable in class io.grpc.netty.NettyServer
- maxTokens - Variable in class io.grpc.internal.RetriableStream.Throttle
-
1000 times the maxTokens field of the retryThrottling policy in service config.
- maxTraceEvents - Variable in class io.grpc.internal.ManagedChannelImpl
- maxTraceEvents - Variable in class io.grpc.internal.ManagedChannelImplBuilder
- maxTraceEvents(int) - Method in class io.grpc.ForwardingChannelBuilder
- maxTraceEvents(int) - Method in class io.grpc.ForwardingChannelBuilder2
- maxTraceEvents(int) - Method in class io.grpc.internal.ManagedChannelImplBuilder
- 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.
- maxWindow() - Method in class io.grpc.netty.AbstractNettyHandler.FlowControlPinger
- maybeChooseServiceConfig(Map<String, ?>, Random, String) - Static method in class io.grpc.internal.DnsNameResolver
-
Determines if a given Service Config choice applies, and if so, returns it.
- maybeExpand() - Method in class io.grpc.Metadata
- maybeForceBuilderInitialization() - Method in class io.grpc.binarylog.v1.ClientHeader.Builder
- maybeForceBuilderInitialization() - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
- maybeForceBuilderInitialization() - Method in class io.grpc.binarylog.v1.ServerHeader.Builder
- maybeForceBuilderInitialization() - Method in class io.grpc.binarylog.v1.Trailer.Builder
- maybeForceBuilderInitialization() - Method in class io.grpc.channelz.v1.Address.OtherAddress.Builder
- maybeForceBuilderInitialization() - Method in class io.grpc.channelz.v1.Channel.Builder
- maybeForceBuilderInitialization() - Method in class io.grpc.channelz.v1.ChannelData.Builder
- maybeForceBuilderInitialization() - Method in class io.grpc.channelz.v1.ChannelTrace.Builder
- maybeForceBuilderInitialization() - Method in class io.grpc.channelz.v1.ChannelTraceEvent.Builder
- maybeForceBuilderInitialization() - Method in class io.grpc.channelz.v1.GetChannelResponse.Builder
- maybeForceBuilderInitialization() - Method in class io.grpc.channelz.v1.GetServerResponse.Builder
- maybeForceBuilderInitialization() - Method in class io.grpc.channelz.v1.GetSocketResponse.Builder
- maybeForceBuilderInitialization() - Method in class io.grpc.channelz.v1.GetSubchannelResponse.Builder
- maybeForceBuilderInitialization() - Method in class io.grpc.channelz.v1.Security.OtherSecurity.Builder
- maybeForceBuilderInitialization() - Method in class io.grpc.channelz.v1.Server.Builder
- maybeForceBuilderInitialization() - Method in class io.grpc.channelz.v1.ServerData.Builder
- maybeForceBuilderInitialization() - Method in class io.grpc.channelz.v1.Socket.Builder
- maybeForceBuilderInitialization() - Method in class io.grpc.channelz.v1.SocketData.Builder
- maybeForceBuilderInitialization() - Method in class io.grpc.channelz.v1.SocketOption.Builder
- maybeForceBuilderInitialization() - Method in class io.grpc.channelz.v1.SocketOptionLinger.Builder
- maybeForceBuilderInitialization() - Method in class io.grpc.channelz.v1.SocketOptionTimeout.Builder
- maybeForceBuilderInitialization() - Method in class io.grpc.channelz.v1.Subchannel.Builder
- maybeForceBuilderInitialization() - Method in class io.grpc.lb.v1.ClientStats.Builder
- maybeForceBuilderInitialization() - Method in class io.grpc.lb.v1.InitialLoadBalanceResponse.Builder
- maybeForceBuilderInitialization() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
- maybeForceBuilderInitialization() - Method in class io.grpc.lookup.v1.RouteLookupClusterSpecifier.Builder
- maybeForceBuilderInitialization() - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
- maybeForceBuilderInitialization() - Method in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
- maybeForceBuilderInitialization() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
- maybeGetTcpUserTimeoutOption() - Static method in class io.grpc.netty.Utils
-
Returns TCP_USER_TIMEOUT channel option for Epoll channel if Epoll is available, otherwise null.
- maybeRefresh() - Method in class io.grpc.rls.CachingRlsLbClient.DataCacheEntry
-
Refreshes cache entry by creating
CachingRlsLbClient.PendingCacheEntry
. - maybeShutdown() - Method in class io.grpc.internal.CallCredentialsApplyingTransportFactory.CallCredentialsApplyingTransport
- maybeShutdownNowSubchannels() - Method in class io.grpc.internal.ManagedChannelImpl
- maybeTerminateChannel() - Method in class io.grpc.internal.ManagedChannelImpl
-
Terminate the channel if termination conditions are met.
- MaybeTruncated(T, boolean) - Constructor for class io.grpc.protobuf.services.BinlogHelper.MaybeTruncated
- maybeUnejectOutliers(Long) - Method in class io.grpc.util.OutlierDetectionLoadBalancer.EndpointTrackerMap
-
At the end of a timer run we need to decrement the ejection time multiplier for trackers that don't have ejected subchannels and uneject ones that have spent the maximum ejection time allowed.
- maybeUpdatePicker() - Method in class io.grpc.grpclb.GrpclbState
-
Make and use a picker out of the current lists and the states of subchannels if they have changed since the last picker created.
- maybeUpdatePicker(ConnectivityState, GrpclbState.RoundRobinPicker) - Method in class io.grpc.grpclb.GrpclbState
-
Update the given picker to the helper if it's different from the current one.
- maybeUseFallbackBackends() - Method in class io.grpc.grpclb.GrpclbState
- mean(Collection<Double>) - Static method in class io.grpc.util.OutlierDetectionLoadBalancer.SuccessRateOutlierEjectionAlgorithm
-
Calculates the mean of the given values.
- memoizedIsInitialized - Variable in class io.grpc.binarylog.v1.Address
- memoizedIsInitialized - Variable in class io.grpc.binarylog.v1.ClientHeader
- memoizedIsInitialized - Variable in class io.grpc.binarylog.v1.GrpcLogEntry
- memoizedIsInitialized - Variable in class io.grpc.binarylog.v1.Message
- memoizedIsInitialized - Variable in class io.grpc.binarylog.v1.Metadata
- memoizedIsInitialized - Variable in class io.grpc.binarylog.v1.MetadataEntry
- memoizedIsInitialized - Variable in class io.grpc.binarylog.v1.ServerHeader
- memoizedIsInitialized - Variable in class io.grpc.binarylog.v1.Trailer
- memoizedIsInitialized - Variable in class io.grpc.channelz.v1.Address
- memoizedIsInitialized - Variable in class io.grpc.channelz.v1.Address.OtherAddress
- memoizedIsInitialized - Variable in class io.grpc.channelz.v1.Address.TcpIpAddress
- memoizedIsInitialized - Variable in class io.grpc.channelz.v1.Address.UdsAddress
- memoizedIsInitialized - Variable in class io.grpc.channelz.v1.Channel
- memoizedIsInitialized - Variable in class io.grpc.channelz.v1.ChannelConnectivityState
- memoizedIsInitialized - Variable in class io.grpc.channelz.v1.ChannelData
- memoizedIsInitialized - Variable in class io.grpc.channelz.v1.ChannelRef
- memoizedIsInitialized - Variable in class io.grpc.channelz.v1.ChannelTrace
- memoizedIsInitialized - Variable in class io.grpc.channelz.v1.ChannelTraceEvent
- memoizedIsInitialized - Variable in class io.grpc.channelz.v1.GetChannelRequest
- memoizedIsInitialized - Variable in class io.grpc.channelz.v1.GetChannelResponse
- memoizedIsInitialized - Variable in class io.grpc.channelz.v1.GetServerRequest
- memoizedIsInitialized - Variable in class io.grpc.channelz.v1.GetServerResponse
- memoizedIsInitialized - Variable in class io.grpc.channelz.v1.GetServerSocketsRequest
- memoizedIsInitialized - Variable in class io.grpc.channelz.v1.GetServerSocketsResponse
- memoizedIsInitialized - Variable in class io.grpc.channelz.v1.GetServersRequest
- memoizedIsInitialized - Variable in class io.grpc.channelz.v1.GetServersResponse
- memoizedIsInitialized - Variable in class io.grpc.channelz.v1.GetSocketRequest
- memoizedIsInitialized - Variable in class io.grpc.channelz.v1.GetSocketResponse
- memoizedIsInitialized - Variable in class io.grpc.channelz.v1.GetSubchannelRequest
- memoizedIsInitialized - Variable in class io.grpc.channelz.v1.GetSubchannelResponse
- memoizedIsInitialized - Variable in class io.grpc.channelz.v1.GetTopChannelsRequest
- memoizedIsInitialized - Variable in class io.grpc.channelz.v1.GetTopChannelsResponse
- memoizedIsInitialized - Variable in class io.grpc.channelz.v1.Security
- memoizedIsInitialized - Variable in class io.grpc.channelz.v1.Security.OtherSecurity
- memoizedIsInitialized - Variable in class io.grpc.channelz.v1.Security.Tls
- memoizedIsInitialized - Variable in class io.grpc.channelz.v1.Server
- memoizedIsInitialized - Variable in class io.grpc.channelz.v1.ServerData
- memoizedIsInitialized - Variable in class io.grpc.channelz.v1.ServerRef
- memoizedIsInitialized - Variable in class io.grpc.channelz.v1.Socket
- memoizedIsInitialized - Variable in class io.grpc.channelz.v1.SocketData
- memoizedIsInitialized - Variable in class io.grpc.channelz.v1.SocketOption
- memoizedIsInitialized - Variable in class io.grpc.channelz.v1.SocketOptionLinger
- memoizedIsInitialized - Variable in class io.grpc.channelz.v1.SocketOptionTcpInfo
- memoizedIsInitialized - Variable in class io.grpc.channelz.v1.SocketOptionTimeout
- memoizedIsInitialized - Variable in class io.grpc.channelz.v1.SocketRef
- memoizedIsInitialized - Variable in class io.grpc.channelz.v1.Subchannel
- memoizedIsInitialized - Variable in class io.grpc.channelz.v1.SubchannelRef
- memoizedIsInitialized - Variable in class io.grpc.health.v1.HealthCheckRequest
- memoizedIsInitialized - Variable in class io.grpc.health.v1.HealthCheckResponse
- memoizedIsInitialized - Variable in class io.grpc.lb.v1.ClientStats
- memoizedIsInitialized - Variable in class io.grpc.lb.v1.ClientStatsPerToken
- memoizedIsInitialized - Variable in class io.grpc.lb.v1.FallbackResponse
- memoizedIsInitialized - Variable in class io.grpc.lb.v1.InitialLoadBalanceRequest
- memoizedIsInitialized - Variable in class io.grpc.lb.v1.InitialLoadBalanceResponse
- memoizedIsInitialized - Variable in class io.grpc.lb.v1.LoadBalanceRequest
- memoizedIsInitialized - Variable in class io.grpc.lb.v1.LoadBalanceResponse
- memoizedIsInitialized - Variable in class io.grpc.lb.v1.Server
- memoizedIsInitialized - Variable in class io.grpc.lb.v1.ServerList
- memoizedIsInitialized - Variable in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys
- memoizedIsInitialized - Variable in class io.grpc.lookup.v1.GrpcKeyBuilder
- memoizedIsInitialized - Variable in class io.grpc.lookup.v1.GrpcKeyBuilder.Name
- memoizedIsInitialized - Variable in class io.grpc.lookup.v1.HttpKeyBuilder
- memoizedIsInitialized - Variable in class io.grpc.lookup.v1.NameMatcher
- memoizedIsInitialized - Variable in class io.grpc.lookup.v1.RouteLookupClusterSpecifier
- memoizedIsInitialized - Variable in class io.grpc.lookup.v1.RouteLookupConfig
- memoizedIsInitialized - Variable in class io.grpc.lookup.v1.RouteLookupRequest
- memoizedIsInitialized - Variable in class io.grpc.lookup.v1.RouteLookupResponse
- memoizedIsInitialized - Variable in class io.grpc.reflection.v1.ErrorResponse
- memoizedIsInitialized - Variable in class io.grpc.reflection.v1.ExtensionNumberResponse
- memoizedIsInitialized - Variable in class io.grpc.reflection.v1.ExtensionRequest
- memoizedIsInitialized - Variable in class io.grpc.reflection.v1.FileDescriptorResponse
- memoizedIsInitialized - Variable in class io.grpc.reflection.v1.ListServiceResponse
- memoizedIsInitialized - Variable in class io.grpc.reflection.v1.ServerReflectionRequest
- memoizedIsInitialized - Variable in class io.grpc.reflection.v1.ServerReflectionResponse
- memoizedIsInitialized - Variable in class io.grpc.reflection.v1.ServiceResponse
- memoizedIsInitialized - Variable in class io.grpc.reflection.v1alpha.ErrorResponse
- memoizedIsInitialized - Variable in class io.grpc.reflection.v1alpha.ExtensionNumberResponse
- memoizedIsInitialized - Variable in class io.grpc.reflection.v1alpha.ExtensionRequest
- memoizedIsInitialized - Variable in class io.grpc.reflection.v1alpha.FileDescriptorResponse
- memoizedIsInitialized - Variable in class io.grpc.reflection.v1alpha.ListServiceResponse
- memoizedIsInitialized - Variable in class io.grpc.reflection.v1alpha.ServerReflectionRequest
- memoizedIsInitialized - Variable in class io.grpc.reflection.v1alpha.ServerReflectionResponse
- memoizedIsInitialized - Variable in class io.grpc.reflection.v1alpha.ServiceResponse
- memoryUtilization - Variable in class io.grpc.services.MetricRecorder
- memoryUtilization - Variable in class io.grpc.services.MetricReport
- memoryUtilizationMetric - Variable in class io.grpc.services.CallMetricRecorder
- 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.
- mergeAdditional(Any) - Method in class io.grpc.channelz.v1.SocketOption.Builder
-
Additional data associated with the socket option.
- mergeAllExtensionNumbersResponse(ExtensionNumberResponse) - Method in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
-
This message is used to answer all_extension_numbers_of_type requests.
- mergeAllExtensionNumbersResponse(ExtensionNumberResponse) - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
-
This message is used to answer all_extension_numbers_of_type requst.
- mergeChannel(Channel) - Method in class io.grpc.channelz.v1.GetChannelResponse.Builder
-
The Channel that corresponds to the requested channel_id.
- mergeChannelRef(ChannelRef) - Method in class io.grpc.channelz.v1.ChannelTraceEvent.Builder
-
.grpc.channelz.v1.ChannelRef channel_ref = 4;
- mergeClientHeader(ClientHeader) - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
.grpc.binarylog.v1.ClientHeader client_header = 6;
- mergeClientStats(ClientStats) - Method in class io.grpc.lb.v1.LoadBalanceRequest.Builder
-
The client stats should be periodically reported to the load balancer based on the duration defined in the InitialLoadBalanceResponse.
- mergeClientStatsReportInterval(Duration) - Method in class io.grpc.lb.v1.InitialLoadBalanceResponse.Builder
-
This interval defines how often the client should send the client stats to the load balancer.
- mergeCreationTimestamp(Timestamp) - Method in class io.grpc.channelz.v1.ChannelTrace.Builder
-
Time that this channel was created.
- mergeData(ChannelData) - Method in class io.grpc.channelz.v1.Channel.Builder
-
Data specific to this channel.
- mergeData(ChannelData) - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
Data specific to this channel.
- mergeData(ServerData) - Method in class io.grpc.channelz.v1.Server.Builder
-
The associated data of the Server.
- mergeData(SocketData) - Method in class io.grpc.channelz.v1.Socket.Builder
-
Data specific to this Socket.
- mergeDuration(Duration) - Method in class io.grpc.channelz.v1.SocketOptionLinger.Builder
-
duration maps to `struct linger.l_linger`
- mergeDuration(Duration) - Method in class io.grpc.channelz.v1.SocketOptionTimeout.Builder
-
.google.protobuf.Duration duration = 1;
- mergeErrorResponse(ErrorResponse) - Method in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
-
This message is used when an error occurs.
- mergeErrorResponse(ErrorResponse) - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
-
This message is used when an error occurs.
- mergeExtraKeys(GrpcKeyBuilder.ExtraKeys) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
-
.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys extra_keys = 3;
- mergeFallbackResponse(FallbackResponse) - Method in class io.grpc.lb.v1.LoadBalanceResponse.Builder
-
If this field is set, then the client should eagerly enter fallback mode (even if there are existing, healthy connections to backends).
- mergeFileContainingExtension(ExtensionRequest) - Method in class io.grpc.reflection.v1.ServerReflectionRequest.Builder
-
Find the proto file which defines an extension extending the given message type with the given field number.
- mergeFileContainingExtension(ExtensionRequest) - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest.Builder
-
Find the proto file which defines an extension extending the given message type with the given field number.
- mergeFileDescriptorResponse(FileDescriptorResponse) - Method in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
-
This message is used to answer file_by_filename, file_containing_symbol, file_containing_extension requests with transitive dependencies.
- mergeFileDescriptorResponse(FileDescriptorResponse) - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
-
This message is used to answer file_by_filename, file_containing_symbol, file_containing_extension requests with transitive dependencies.
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.binarylog.v1.Address.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.binarylog.v1.ClientHeader.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.binarylog.v1.Message.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.binarylog.v1.Metadata.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.binarylog.v1.MetadataEntry.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.binarylog.v1.ServerHeader.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.binarylog.v1.Trailer.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.channelz.v1.Address.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.channelz.v1.Address.OtherAddress.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.channelz.v1.Address.TcpIpAddress.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.channelz.v1.Address.UdsAddress.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.channelz.v1.Channel.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.channelz.v1.ChannelConnectivityState.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.channelz.v1.ChannelData.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.channelz.v1.ChannelRef.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.channelz.v1.ChannelTrace.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.channelz.v1.ChannelTraceEvent.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.channelz.v1.GetChannelRequest.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.channelz.v1.GetChannelResponse.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.channelz.v1.GetServerRequest.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.channelz.v1.GetServerResponse.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.channelz.v1.GetServerSocketsRequest.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.channelz.v1.GetServerSocketsResponse.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.channelz.v1.GetServersRequest.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.channelz.v1.GetServersResponse.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.channelz.v1.GetSocketRequest.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.channelz.v1.GetSocketResponse.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.channelz.v1.GetSubchannelRequest.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.channelz.v1.GetSubchannelResponse.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.channelz.v1.GetTopChannelsRequest.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.channelz.v1.GetTopChannelsResponse.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.channelz.v1.Security.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.channelz.v1.Security.OtherSecurity.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.channelz.v1.Security.Tls.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.channelz.v1.Server.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.channelz.v1.ServerData.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.channelz.v1.ServerRef.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.channelz.v1.Socket.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.channelz.v1.SocketData.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.channelz.v1.SocketOption.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.channelz.v1.SocketOptionLinger.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.channelz.v1.SocketOptionTimeout.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.channelz.v1.SocketRef.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.channelz.v1.Subchannel.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.channelz.v1.SubchannelRef.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.health.v1.HealthCheckRequest.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.health.v1.HealthCheckResponse.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.lb.v1.ClientStats.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.lb.v1.ClientStatsPerToken.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.lb.v1.FallbackResponse.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.lb.v1.InitialLoadBalanceRequest.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.lb.v1.InitialLoadBalanceResponse.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.lb.v1.LoadBalanceRequest.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.lb.v1.LoadBalanceResponse.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.lb.v1.Server.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.lb.v1.ServerList.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Name.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.lookup.v1.NameMatcher.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.lookup.v1.RouteLookupClusterSpecifier.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.lookup.v1.RouteLookupRequest.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.lookup.v1.RouteLookupResponse.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.reflection.v1.ErrorResponse.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.reflection.v1.ExtensionNumberResponse.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.reflection.v1.ExtensionRequest.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.reflection.v1.FileDescriptorResponse.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.reflection.v1.ListServiceResponse.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.reflection.v1.ServerReflectionRequest.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.reflection.v1.ServiceResponse.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.reflection.v1alpha.ErrorResponse.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.reflection.v1alpha.ExtensionNumberResponse.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.reflection.v1alpha.ExtensionRequest.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.reflection.v1alpha.FileDescriptorResponse.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.reflection.v1alpha.ListServiceResponse.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
- mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class io.grpc.reflection.v1alpha.ServiceResponse.Builder
- mergeFrom(Message) - Method in class io.grpc.binarylog.v1.Address.Builder
- mergeFrom(Message) - Method in class io.grpc.binarylog.v1.ClientHeader.Builder
- mergeFrom(Message) - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
- mergeFrom(Message) - Method in class io.grpc.binarylog.v1.Message.Builder
- mergeFrom(Message) - Method in class io.grpc.binarylog.v1.Metadata.Builder
- mergeFrom(Message) - Method in class io.grpc.binarylog.v1.MetadataEntry.Builder
- mergeFrom(Message) - Method in class io.grpc.binarylog.v1.ServerHeader.Builder
- mergeFrom(Message) - Method in class io.grpc.binarylog.v1.Trailer.Builder
- mergeFrom(Message) - Method in class io.grpc.channelz.v1.Address.Builder
- mergeFrom(Message) - Method in class io.grpc.channelz.v1.Address.OtherAddress.Builder
- mergeFrom(Message) - Method in class io.grpc.channelz.v1.Address.TcpIpAddress.Builder
- mergeFrom(Message) - Method in class io.grpc.channelz.v1.Address.UdsAddress.Builder
- mergeFrom(Message) - Method in class io.grpc.channelz.v1.Channel.Builder
- mergeFrom(Message) - Method in class io.grpc.channelz.v1.ChannelConnectivityState.Builder
- mergeFrom(Message) - Method in class io.grpc.channelz.v1.ChannelData.Builder
- mergeFrom(Message) - Method in class io.grpc.channelz.v1.ChannelRef.Builder
- mergeFrom(Message) - Method in class io.grpc.channelz.v1.ChannelTrace.Builder
- mergeFrom(Message) - Method in class io.grpc.channelz.v1.ChannelTraceEvent.Builder
- mergeFrom(Message) - Method in class io.grpc.channelz.v1.GetChannelRequest.Builder
- mergeFrom(Message) - Method in class io.grpc.channelz.v1.GetChannelResponse.Builder
- mergeFrom(Message) - Method in class io.grpc.channelz.v1.GetServerRequest.Builder
- mergeFrom(Message) - Method in class io.grpc.channelz.v1.GetServerResponse.Builder
- mergeFrom(Message) - Method in class io.grpc.channelz.v1.GetServerSocketsRequest.Builder
- mergeFrom(Message) - Method in class io.grpc.channelz.v1.GetServerSocketsResponse.Builder
- mergeFrom(Message) - Method in class io.grpc.channelz.v1.GetServersRequest.Builder
- mergeFrom(Message) - Method in class io.grpc.channelz.v1.GetServersResponse.Builder
- mergeFrom(Message) - Method in class io.grpc.channelz.v1.GetSocketRequest.Builder
- mergeFrom(Message) - Method in class io.grpc.channelz.v1.GetSocketResponse.Builder
- mergeFrom(Message) - Method in class io.grpc.channelz.v1.GetSubchannelRequest.Builder
- mergeFrom(Message) - Method in class io.grpc.channelz.v1.GetSubchannelResponse.Builder
- mergeFrom(Message) - Method in class io.grpc.channelz.v1.GetTopChannelsRequest.Builder
- mergeFrom(Message) - Method in class io.grpc.channelz.v1.GetTopChannelsResponse.Builder
- mergeFrom(Message) - Method in class io.grpc.channelz.v1.Security.Builder
- mergeFrom(Message) - Method in class io.grpc.channelz.v1.Security.OtherSecurity.Builder
- mergeFrom(Message) - Method in class io.grpc.channelz.v1.Security.Tls.Builder
- mergeFrom(Message) - Method in class io.grpc.channelz.v1.Server.Builder
- mergeFrom(Message) - Method in class io.grpc.channelz.v1.ServerData.Builder
- mergeFrom(Message) - Method in class io.grpc.channelz.v1.ServerRef.Builder
- mergeFrom(Message) - Method in class io.grpc.channelz.v1.Socket.Builder
- mergeFrom(Message) - Method in class io.grpc.channelz.v1.SocketData.Builder
- mergeFrom(Message) - Method in class io.grpc.channelz.v1.SocketOption.Builder
- mergeFrom(Message) - Method in class io.grpc.channelz.v1.SocketOptionLinger.Builder
- mergeFrom(Message) - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
- mergeFrom(Message) - Method in class io.grpc.channelz.v1.SocketOptionTimeout.Builder
- mergeFrom(Message) - Method in class io.grpc.channelz.v1.SocketRef.Builder
- mergeFrom(Message) - Method in class io.grpc.channelz.v1.Subchannel.Builder
- mergeFrom(Message) - Method in class io.grpc.channelz.v1.SubchannelRef.Builder
- mergeFrom(Message) - Method in class io.grpc.health.v1.HealthCheckRequest.Builder
- mergeFrom(Message) - Method in class io.grpc.health.v1.HealthCheckResponse.Builder
- mergeFrom(Message) - Method in class io.grpc.lb.v1.ClientStats.Builder
- mergeFrom(Message) - Method in class io.grpc.lb.v1.ClientStatsPerToken.Builder
- mergeFrom(Message) - Method in class io.grpc.lb.v1.FallbackResponse.Builder
- mergeFrom(Message) - Method in class io.grpc.lb.v1.InitialLoadBalanceRequest.Builder
- mergeFrom(Message) - Method in class io.grpc.lb.v1.InitialLoadBalanceResponse.Builder
- mergeFrom(Message) - Method in class io.grpc.lb.v1.LoadBalanceRequest.Builder
- mergeFrom(Message) - Method in class io.grpc.lb.v1.LoadBalanceResponse.Builder
- mergeFrom(Message) - Method in class io.grpc.lb.v1.Server.Builder
- mergeFrom(Message) - Method in class io.grpc.lb.v1.ServerList.Builder
- mergeFrom(Message) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
- mergeFrom(Message) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys.Builder
- mergeFrom(Message) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Name.Builder
- mergeFrom(Message) - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
- mergeFrom(Message) - Method in class io.grpc.lookup.v1.NameMatcher.Builder
- mergeFrom(Message) - Method in class io.grpc.lookup.v1.RouteLookupClusterSpecifier.Builder
- mergeFrom(Message) - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
- mergeFrom(Message) - Method in class io.grpc.lookup.v1.RouteLookupRequest.Builder
- mergeFrom(Message) - Method in class io.grpc.lookup.v1.RouteLookupResponse.Builder
- mergeFrom(Message) - Method in class io.grpc.reflection.v1.ErrorResponse.Builder
- mergeFrom(Message) - Method in class io.grpc.reflection.v1.ExtensionNumberResponse.Builder
- mergeFrom(Message) - Method in class io.grpc.reflection.v1.ExtensionRequest.Builder
- mergeFrom(Message) - Method in class io.grpc.reflection.v1.FileDescriptorResponse.Builder
- mergeFrom(Message) - Method in class io.grpc.reflection.v1.ListServiceResponse.Builder
- mergeFrom(Message) - Method in class io.grpc.reflection.v1.ServerReflectionRequest.Builder
- mergeFrom(Message) - Method in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
- mergeFrom(Message) - Method in class io.grpc.reflection.v1.ServiceResponse.Builder
- mergeFrom(Message) - Method in class io.grpc.reflection.v1alpha.ErrorResponse.Builder
- mergeFrom(Message) - Method in class io.grpc.reflection.v1alpha.ExtensionNumberResponse.Builder
- mergeFrom(Message) - Method in class io.grpc.reflection.v1alpha.ExtensionRequest.Builder
- mergeFrom(Message) - Method in class io.grpc.reflection.v1alpha.FileDescriptorResponse.Builder
- mergeFrom(Message) - Method in class io.grpc.reflection.v1alpha.ListServiceResponse.Builder
- mergeFrom(Message) - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest.Builder
- mergeFrom(Message) - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
- mergeFrom(Message) - Method in class io.grpc.reflection.v1alpha.ServiceResponse.Builder
- mergeFrom(Address) - Method in class io.grpc.binarylog.v1.Address.Builder
- mergeFrom(ClientHeader) - Method in class io.grpc.binarylog.v1.ClientHeader.Builder
- mergeFrom(GrpcLogEntry) - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
- mergeFrom(Message) - Method in class io.grpc.binarylog.v1.Message.Builder
- mergeFrom(Metadata) - Method in class io.grpc.binarylog.v1.Metadata.Builder
- mergeFrom(MetadataEntry) - Method in class io.grpc.binarylog.v1.MetadataEntry.Builder
- mergeFrom(ServerHeader) - Method in class io.grpc.binarylog.v1.ServerHeader.Builder
- mergeFrom(Trailer) - Method in class io.grpc.binarylog.v1.Trailer.Builder
- mergeFrom(Address) - Method in class io.grpc.channelz.v1.Address.Builder
- mergeFrom(Address.OtherAddress) - Method in class io.grpc.channelz.v1.Address.OtherAddress.Builder
- mergeFrom(Address.TcpIpAddress) - Method in class io.grpc.channelz.v1.Address.TcpIpAddress.Builder
- mergeFrom(Address.UdsAddress) - Method in class io.grpc.channelz.v1.Address.UdsAddress.Builder
- mergeFrom(Channel) - Method in class io.grpc.channelz.v1.Channel.Builder
- mergeFrom(ChannelConnectivityState) - Method in class io.grpc.channelz.v1.ChannelConnectivityState.Builder
- mergeFrom(ChannelData) - Method in class io.grpc.channelz.v1.ChannelData.Builder
- mergeFrom(ChannelRef) - Method in class io.grpc.channelz.v1.ChannelRef.Builder
- mergeFrom(ChannelTrace) - Method in class io.grpc.channelz.v1.ChannelTrace.Builder
- mergeFrom(ChannelTraceEvent) - Method in class io.grpc.channelz.v1.ChannelTraceEvent.Builder
- mergeFrom(GetChannelRequest) - Method in class io.grpc.channelz.v1.GetChannelRequest.Builder
- mergeFrom(GetChannelResponse) - Method in class io.grpc.channelz.v1.GetChannelResponse.Builder
- mergeFrom(GetServerRequest) - Method in class io.grpc.channelz.v1.GetServerRequest.Builder
- mergeFrom(GetServerResponse) - Method in class io.grpc.channelz.v1.GetServerResponse.Builder
- mergeFrom(GetServerSocketsRequest) - Method in class io.grpc.channelz.v1.GetServerSocketsRequest.Builder
- mergeFrom(GetServerSocketsResponse) - Method in class io.grpc.channelz.v1.GetServerSocketsResponse.Builder
- mergeFrom(GetServersRequest) - Method in class io.grpc.channelz.v1.GetServersRequest.Builder
- mergeFrom(GetServersResponse) - Method in class io.grpc.channelz.v1.GetServersResponse.Builder
- mergeFrom(GetSocketRequest) - Method in class io.grpc.channelz.v1.GetSocketRequest.Builder
- mergeFrom(GetSocketResponse) - Method in class io.grpc.channelz.v1.GetSocketResponse.Builder
- mergeFrom(GetSubchannelRequest) - Method in class io.grpc.channelz.v1.GetSubchannelRequest.Builder
- mergeFrom(GetSubchannelResponse) - Method in class io.grpc.channelz.v1.GetSubchannelResponse.Builder
- mergeFrom(GetTopChannelsRequest) - Method in class io.grpc.channelz.v1.GetTopChannelsRequest.Builder
- mergeFrom(GetTopChannelsResponse) - Method in class io.grpc.channelz.v1.GetTopChannelsResponse.Builder
- mergeFrom(Security) - Method in class io.grpc.channelz.v1.Security.Builder
- mergeFrom(Security.OtherSecurity) - Method in class io.grpc.channelz.v1.Security.OtherSecurity.Builder
- mergeFrom(Security.Tls) - Method in class io.grpc.channelz.v1.Security.Tls.Builder
- mergeFrom(Server) - Method in class io.grpc.channelz.v1.Server.Builder
- mergeFrom(ServerData) - Method in class io.grpc.channelz.v1.ServerData.Builder
- mergeFrom(ServerRef) - Method in class io.grpc.channelz.v1.ServerRef.Builder
- mergeFrom(Socket) - Method in class io.grpc.channelz.v1.Socket.Builder
- mergeFrom(SocketData) - Method in class io.grpc.channelz.v1.SocketData.Builder
- mergeFrom(SocketOption) - Method in class io.grpc.channelz.v1.SocketOption.Builder
- mergeFrom(SocketOptionLinger) - Method in class io.grpc.channelz.v1.SocketOptionLinger.Builder
- mergeFrom(SocketOptionTcpInfo) - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
- mergeFrom(SocketOptionTimeout) - Method in class io.grpc.channelz.v1.SocketOptionTimeout.Builder
- mergeFrom(SocketRef) - Method in class io.grpc.channelz.v1.SocketRef.Builder
- mergeFrom(Subchannel) - Method in class io.grpc.channelz.v1.Subchannel.Builder
- mergeFrom(SubchannelRef) - Method in class io.grpc.channelz.v1.SubchannelRef.Builder
- mergeFrom(HealthCheckRequest) - Method in class io.grpc.health.v1.HealthCheckRequest.Builder
- mergeFrom(HealthCheckResponse) - Method in class io.grpc.health.v1.HealthCheckResponse.Builder
- mergeFrom(ClientStats) - Method in class io.grpc.lb.v1.ClientStats.Builder
- mergeFrom(ClientStatsPerToken) - Method in class io.grpc.lb.v1.ClientStatsPerToken.Builder
- mergeFrom(FallbackResponse) - Method in class io.grpc.lb.v1.FallbackResponse.Builder
- mergeFrom(InitialLoadBalanceRequest) - Method in class io.grpc.lb.v1.InitialLoadBalanceRequest.Builder
- mergeFrom(InitialLoadBalanceResponse) - Method in class io.grpc.lb.v1.InitialLoadBalanceResponse.Builder
- mergeFrom(LoadBalanceRequest) - Method in class io.grpc.lb.v1.LoadBalanceRequest.Builder
- mergeFrom(LoadBalanceResponse) - Method in class io.grpc.lb.v1.LoadBalanceResponse.Builder
- mergeFrom(Server) - Method in class io.grpc.lb.v1.Server.Builder
- mergeFrom(ServerList) - Method in class io.grpc.lb.v1.ServerList.Builder
- mergeFrom(GrpcKeyBuilder) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
- mergeFrom(GrpcKeyBuilder.ExtraKeys) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys.Builder
- mergeFrom(GrpcKeyBuilder.Name) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Name.Builder
- mergeFrom(HttpKeyBuilder) - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
- mergeFrom(NameMatcher) - Method in class io.grpc.lookup.v1.NameMatcher.Builder
- mergeFrom(RouteLookupClusterSpecifier) - Method in class io.grpc.lookup.v1.RouteLookupClusterSpecifier.Builder
- mergeFrom(RouteLookupConfig) - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
- mergeFrom(RouteLookupRequest) - Method in class io.grpc.lookup.v1.RouteLookupRequest.Builder
- mergeFrom(RouteLookupResponse) - Method in class io.grpc.lookup.v1.RouteLookupResponse.Builder
- mergeFrom(ErrorResponse) - Method in class io.grpc.reflection.v1.ErrorResponse.Builder
- mergeFrom(ExtensionNumberResponse) - Method in class io.grpc.reflection.v1.ExtensionNumberResponse.Builder
- mergeFrom(ExtensionRequest) - Method in class io.grpc.reflection.v1.ExtensionRequest.Builder
- mergeFrom(FileDescriptorResponse) - Method in class io.grpc.reflection.v1.FileDescriptorResponse.Builder
- mergeFrom(ListServiceResponse) - Method in class io.grpc.reflection.v1.ListServiceResponse.Builder
- mergeFrom(ServerReflectionRequest) - Method in class io.grpc.reflection.v1.ServerReflectionRequest.Builder
- mergeFrom(ServerReflectionResponse) - Method in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
- mergeFrom(ServiceResponse) - Method in class io.grpc.reflection.v1.ServiceResponse.Builder
- mergeFrom(ErrorResponse) - Method in class io.grpc.reflection.v1alpha.ErrorResponse.Builder
- mergeFrom(ExtensionNumberResponse) - Method in class io.grpc.reflection.v1alpha.ExtensionNumberResponse.Builder
- mergeFrom(ExtensionRequest) - Method in class io.grpc.reflection.v1alpha.ExtensionRequest.Builder
- mergeFrom(FileDescriptorResponse) - Method in class io.grpc.reflection.v1alpha.FileDescriptorResponse.Builder
- mergeFrom(ListServiceResponse) - Method in class io.grpc.reflection.v1alpha.ListServiceResponse.Builder
- mergeFrom(ServerReflectionRequest) - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest.Builder
- mergeFrom(ServerReflectionResponse) - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
- mergeFrom(ServiceResponse) - Method in class io.grpc.reflection.v1alpha.ServiceResponse.Builder
- mergeInitialRequest(InitialLoadBalanceRequest) - Method in class io.grpc.lb.v1.LoadBalanceRequest.Builder
-
This message should be sent on the first request to the load balancer.
- mergeInitialResponse(InitialLoadBalanceResponse) - Method in class io.grpc.lb.v1.LoadBalanceResponse.Builder
-
This message should be sent on the first response to the client.
- mergeLastCallStartedTimestamp(Timestamp) - Method in class io.grpc.channelz.v1.ChannelData.Builder
-
The last time a call was started on the channel.
- mergeLastCallStartedTimestamp(Timestamp) - Method in class io.grpc.channelz.v1.ServerData.Builder
-
The last time a call was started on the server.
- mergeLastLocalStreamCreatedTimestamp(Timestamp) - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The last time a stream was created by this endpoint.
- mergeLastMessageReceivedTimestamp(Timestamp) - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The last time a message was received by this endpoint.
- mergeLastMessageSentTimestamp(Timestamp) - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The last time a message was sent by this endpoint.
- mergeLastRemoteStreamCreatedTimestamp(Timestamp) - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The last time a stream was created by the remote endpoint.
- mergeListServicesResponse(ListServiceResponse) - Method in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
-
This message is used to answer list_services requests.
- mergeListServicesResponse(ListServiceResponse) - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
-
This message is used to answer list_services request.
- mergeLocal(Address) - Method in class io.grpc.channelz.v1.Socket.Builder
-
The locally bound address.
- mergeLocalFlowControlWindow(Int64Value) - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The amount of window, granted to the local endpoint by the remote endpoint.
- mergeLookupServiceTimeout(Duration) - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
Configure a timeout value for lookup service requests.
- mergeMaxAge(Duration) - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
How long are responses valid for (like HTTP Cache-Control).
- mergeMessage(Message) - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
Used by EVENT_TYPE_CLIENT_MESSAGE, EVENT_TYPE_SERVER_MESSAGE
- mergeMetadata(Metadata) - Method in class io.grpc.binarylog.v1.ClientHeader.Builder
-
This contains only the metadata from the application.
- mergeMetadata(Metadata) - Method in class io.grpc.binarylog.v1.ServerHeader.Builder
-
This contains only the metadata from the application.
- mergeMetadata(Metadata) - Method in class io.grpc.binarylog.v1.Trailer.Builder
-
This contains only the metadata from the application.
- mergeOriginalRequest(ServerReflectionRequest) - Method in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
-
.grpc.reflection.v1.ServerReflectionRequest original_request = 2;
- mergeOriginalRequest(ServerReflectionRequest) - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
-
.grpc.reflection.v1alpha.ServerReflectionRequest original_request = 2;
- mergeOther(Security.OtherSecurity) - Method in class io.grpc.channelz.v1.Security.Builder
-
.grpc.channelz.v1.Security.OtherSecurity other = 2;
- mergeOtherAddress(Address.OtherAddress) - Method in class io.grpc.channelz.v1.Address.Builder
-
.grpc.channelz.v1.Address.OtherAddress other_address = 3;
- mergePeer(Address) - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
Peer address information, will only be recorded on the first incoming event.
- mergeRef(ChannelRef) - Method in class io.grpc.channelz.v1.Channel.Builder
-
The identifier for this channel.
- mergeRef(ServerRef) - Method in class io.grpc.channelz.v1.Server.Builder
-
The identifier for a Server.
- mergeRef(SocketRef) - Method in class io.grpc.channelz.v1.Socket.Builder
-
The identifier for the Socket.
- mergeRef(SubchannelRef) - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
The identifier for this channel.
- mergeRemote(Address) - Method in class io.grpc.channelz.v1.Socket.Builder
-
The remote bound address.
- mergeRemoteFlowControlWindow(Int64Value) - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The amount of window, granted to the remote endpoint by the local endpoint.
- mergeRouteLookupConfig(RouteLookupConfig) - Method in class io.grpc.lookup.v1.RouteLookupClusterSpecifier.Builder
-
The RLS config for this cluster specifier plugin instance.
- mergeSecurity(Security) - Method in class io.grpc.channelz.v1.Socket.Builder
-
Security details for this socket.
- mergeServer(Server) - Method in class io.grpc.channelz.v1.GetServerResponse.Builder
-
The Server that corresponds to the requested server_id.
- mergeServerHeader(ServerHeader) - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
.grpc.binarylog.v1.ServerHeader server_header = 7;
- mergeServerList(ServerList) - Method in class io.grpc.lb.v1.LoadBalanceResponse.Builder
-
Contains the list of servers selected by the load balancer.
- mergeSocket(Socket) - Method in class io.grpc.channelz.v1.GetSocketResponse.Builder
-
The Socket that corresponds to the requested socket_id.
- mergeStaleAge(Duration) - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
After a response has been in the client cache for this amount of time and is re-requested, start an asynchronous RPC to re-validate it.
- mergeState(ChannelConnectivityState) - Method in class io.grpc.channelz.v1.ChannelData.Builder
-
The connectivity state of the channel or subchannel.
- mergeSubchannel(Subchannel) - Method in class io.grpc.channelz.v1.GetSubchannelResponse.Builder
-
The Subchannel that corresponds to the requested subchannel_id.
- mergeSubchannelRef(SubchannelRef) - Method in class io.grpc.channelz.v1.ChannelTraceEvent.Builder
-
.grpc.channelz.v1.SubchannelRef subchannel_ref = 5;
- mergeTcpipAddress(Address.TcpIpAddress) - Method in class io.grpc.channelz.v1.Address.Builder
-
.grpc.channelz.v1.Address.TcpIpAddress tcpip_address = 1;
- mergeTimeout(Duration) - Method in class io.grpc.binarylog.v1.ClientHeader.Builder
-
the RPC timeout
- mergeTimestamp(Timestamp) - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
The timestamp of the binary log message
- mergeTimestamp(Timestamp) - Method in class io.grpc.channelz.v1.ChannelTraceEvent.Builder
-
When this event occurred.
- mergeTimestamp(Timestamp) - Method in class io.grpc.lb.v1.ClientStats.Builder
-
The timestamp of generating the report.
- mergeTls(Security.Tls) - Method in class io.grpc.channelz.v1.Security.Builder
-
.grpc.channelz.v1.Security.Tls tls = 1;
- mergeTrace(ChannelTrace) - Method in class io.grpc.channelz.v1.ChannelData.Builder
-
A trace of recent events on the channel.
- mergeTrace(ChannelTrace) - Method in class io.grpc.channelz.v1.ServerData.Builder
-
A trace of recent events on the server.
- mergeTrailer(Trailer) - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
.grpc.binarylog.v1.Trailer trailer = 9;
- mergeUdsAddress(Address.UdsAddress) - Method in class io.grpc.channelz.v1.Address.Builder
-
.grpc.channelz.v1.Address.UdsAddress uds_address = 2;
- mergeValue(Any) - Method in class io.grpc.channelz.v1.Address.OtherAddress.Builder
-
The actual address message.
- mergeValue(Any) - Method in class io.grpc.channelz.v1.Security.OtherSecurity.Builder
-
The actual security details message.
- mergeWithCompositeTail(ByteBufAllocator, CompositeByteBuf, ByteBuf) - Static method in class io.grpc.netty.NettyAdaptiveCumulator
-
Append the given
ByteBuf
in
toCompositeByteBuf
composite
by expanding or replacing the tail component of theCompositeByteBuf
. - message - Variable in class io.grpc.inprocess.InProcessTransport.SingleMessageProducer
- message - Variable in class io.grpc.internal.MessageDeframer.SingleMessageProducer
- message - Variable in class io.grpc.protobuf.lite.ProtoInputStream
- message() - Method in class io.grpc.protobuf.lite.ProtoInputStream
- Message - Class in io.grpc.binarylog.v1
-
Message payload, used by CLIENT_MESSAGE and SERVER_MESSAGE
- Message() - Constructor for class io.grpc.binarylog.v1.Message
- Message(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.binarylog.v1.Message
- MESSAGE - Enum constant in enum io.grpc.binarylog.v1.GrpcLogEntry.PayloadCase
- MESSAGE_ACCEPT_ENCODING - Static variable in class io.grpc.internal.GrpcUtil
-
The accepted message encodings (i.e.
- MESSAGE_ACCEPT_ENCODING_KEY - Static variable in class io.grpc.internal.GrpcUtil
-
Metadata.Key
for the accepted message encodings header. - MESSAGE_ENCODING - Static variable in class io.grpc.internal.GrpcUtil
-
The message encoding (i.e.
- MESSAGE_ENCODING_KEY - Static variable in class io.grpc.internal.GrpcUtil
-
Metadata.Key
for the message encoding header. - MESSAGE_FIELD_NUMBER - Static variable in class io.grpc.binarylog.v1.GrpcLogEntry
- MESSAGE_KEY - Static variable in class io.grpc.InternalStatus
-
Key to bind status message to trailing metadata.
- MESSAGE_KEY - Static variable in class io.grpc.Status
-
Key to bind status message to trailing metadata.
- Message.Builder - Class in io.grpc.binarylog.v1
-
Message payload, used by CLIENT_MESSAGE and SERVER_MESSAGE
- messageAcceptEncoding - Variable in class io.grpc.internal.ServerCallImpl
- messageBuilder_ - Variable in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
- messageCompression - Variable in class io.grpc.internal.MessageFramer
- 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.
- MessageDeframer.SingleMessageProducer - Class in io.grpc.internal
- MessageDeframer.SizeEnforcingInputStream - Class in io.grpc.internal
-
An
InputStream
that enforces theMessageDeframer.SizeEnforcingInputStream.maxMessageSize
limit for compressed frames. - MessageDeframer.State - Enum in io.grpc.internal
- 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.BufferChainOutputStream - Class in io.grpc.internal
-
Produce a collection of
WritableBuffer
instances from the data written to anOutputStream
. - MessageFramer.OutputStreamAdapter - Class in io.grpc.internal
-
OutputStream whose write()s are passed to the framer.
- MessageFramer.Sink - Interface in io.grpc.internal
-
Sink implemented by the transport layer to receive frames and forward them to their destination.
- MessageMarshaller(T, int) - Constructor for class io.grpc.protobuf.lite.ProtoLiteUtils.MessageMarshaller
- MessageOrBuilder - Interface in io.grpc.binarylog.v1
- messageProducer - Variable in class io.grpc.internal.MigratingThreadDeframer
- messageProducerEnqueued - Variable in class io.grpc.internal.MigratingThreadDeframer
- messageReadQueue - Variable in class io.grpc.internal.ApplicationThreadDeframerListener
-
Queue for messages returned by the deframer when deframing in the application thread.
- messageReadQueuePoll() - Method in class io.grpc.internal.ApplicationThreadDeframerListener
- messageRequest_ - Variable in class io.grpc.reflection.v1.ServerReflectionRequest.Builder
- messageRequest_ - Variable in class io.grpc.reflection.v1.ServerReflectionRequest
- messageRequest_ - Variable in class io.grpc.reflection.v1alpha.ServerReflectionRequest.Builder
- messageRequest_ - Variable in class io.grpc.reflection.v1alpha.ServerReflectionRequest
- MESSAGEREQUEST_NOT_SET - Enum constant in enum io.grpc.reflection.v1.ServerReflectionRequest.MessageRequestCase
- MESSAGEREQUEST_NOT_SET - Enum constant in enum io.grpc.reflection.v1alpha.ServerReflectionRequest.MessageRequestCase
- MessageRequestCase(int) - Constructor for enum io.grpc.reflection.v1.ServerReflectionRequest.MessageRequestCase
- MessageRequestCase(int) - Constructor for enum io.grpc.reflection.v1alpha.ServerReflectionRequest.MessageRequestCase
- messageRequestCase_ - Variable in class io.grpc.reflection.v1.ServerReflectionRequest.Builder
- messageRequestCase_ - Variable in class io.grpc.reflection.v1.ServerReflectionRequest
- messageRequestCase_ - Variable in class io.grpc.reflection.v1alpha.ServerReflectionRequest.Builder
- messageRequestCase_ - Variable in class io.grpc.reflection.v1alpha.ServerReflectionRequest
- messageResponse_ - Variable in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
- messageResponse_ - Variable in class io.grpc.reflection.v1.ServerReflectionResponse
- messageResponse_ - Variable in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
- messageResponse_ - Variable in class io.grpc.reflection.v1alpha.ServerReflectionResponse
- MESSAGERESPONSE_NOT_SET - Enum constant in enum io.grpc.reflection.v1.ServerReflectionResponse.MessageResponseCase
- MESSAGERESPONSE_NOT_SET - Enum constant in enum io.grpc.reflection.v1alpha.ServerReflectionResponse.MessageResponseCase
- MessageResponseCase(int) - Constructor for enum io.grpc.reflection.v1.ServerReflectionResponse.MessageResponseCase
- MessageResponseCase(int) - Constructor for enum io.grpc.reflection.v1alpha.ServerReflectionResponse.MessageResponseCase
- messageResponseCase_ - Variable in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
- messageResponseCase_ - Variable in class io.grpc.reflection.v1.ServerReflectionResponse
- messageResponseCase_ - Variable in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
- messageResponseCase_ - Variable in class io.grpc.reflection.v1alpha.ServerReflectionResponse
- MESSAGES_RECEIVED_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.SocketData
- MESSAGES_SENT_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.SocketData
- messagesAvailable(StreamListener.MessageProducer) - Method in class io.grpc.internal.AbstractStream.TransportState
- messagesAvailable(StreamListener.MessageProducer) - Method in class io.grpc.internal.ApplicationThreadDeframerListener
- messagesAvailable(StreamListener.MessageProducer) - Method in class io.grpc.internal.ClientCallImpl.ClientStreamListenerImpl
- messagesAvailable(StreamListener.MessageProducer) - Method in class io.grpc.internal.DelayedStream.DelayedStreamListener
- messagesAvailable(StreamListener.MessageProducer) - Method in class io.grpc.internal.ForwardingClientStreamListener
- messagesAvailable(StreamListener.MessageProducer) - Method in class io.grpc.internal.ForwardingDeframerListener
- messagesAvailable(StreamListener.MessageProducer) - Method in interface io.grpc.internal.MessageDeframer.Listener
-
Called to deliver the next complete message.
- messagesAvailable(StreamListener.MessageProducer) - Method in class io.grpc.internal.RetriableStream.Sublistener
- messagesAvailable(StreamListener.MessageProducer) - Method in class io.grpc.internal.ServerCallImpl.ServerStreamListenerImpl
- messagesAvailable(StreamListener.MessageProducer) - Method in class io.grpc.internal.ServerImpl.JumpToApplicationThreadServerStreamListener
- messagesAvailable(StreamListener.MessageProducer) - Method in class io.grpc.internal.ServerImpl.NoopListener
- messagesAvailable(StreamListener.MessageProducer) - Method in class io.grpc.internal.SquelchLateMessagesAvailableDeframerListener
- messagesAvailable(StreamListener.MessageProducer) - Method in interface io.grpc.internal.StreamListener
-
Called upon receiving a message from the remote end-point.
- messagesAvailableInternal(StreamListener.MessageProducer) - Method in class io.grpc.internal.ServerCallImpl.ServerStreamListenerImpl
- messagesBuffered - Variable in class io.grpc.internal.MessageFramer
- messageSent - Variable in class io.grpc.internal.ServerCallImpl
- messagesReceived - Variable in class io.grpc.internal.TransportTracer
- messagesReceived - Variable in class io.grpc.InternalChannelz.TransportStats
- messagesReceived_ - Variable in class io.grpc.channelz.v1.SocketData.Builder
- messagesReceived_ - Variable in class io.grpc.channelz.v1.SocketData
- messagesSent - Variable in class io.grpc.internal.TransportTracer
- messagesSent - Variable in class io.grpc.InternalChannelz.TransportStats
- messagesSent_ - Variable in class io.grpc.channelz.v1.SocketData.Builder
- messagesSent_ - Variable in class io.grpc.channelz.v1.SocketData
- metadata - Variable in class io.grpc.internal.RetriableStream.SavedCloseMasterListenerReason
- Metadata - Class in io.grpc.binarylog.v1
-
A list of metadata pairs, used in the payload of client header, server header, and server trailer.
- 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.binarylog.v1.Metadata
- Metadata() - Constructor for class io.grpc.Metadata
-
Constructor called by the application layer when it wants to send metadata.
- Metadata(byte[]...) - Constructor for class io.grpc.Metadata
-
Constructor called by the transport layer when it receives binary metadata.
- Metadata(int, byte[]...) - Constructor for class io.grpc.Metadata
-
Constructor called by the transport layer when it receives binary metadata.
- Metadata(int, Object[]) - Constructor for class io.grpc.Metadata
-
Constructor called by the transport layer when it receives partially-parsed metadata.
- Metadata(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.binarylog.v1.Metadata
- metadata_ - Variable in class io.grpc.binarylog.v1.ClientHeader.Builder
- metadata_ - Variable in class io.grpc.binarylog.v1.ClientHeader
- metadata_ - Variable in class io.grpc.binarylog.v1.ServerHeader.Builder
- metadata_ - Variable in class io.grpc.binarylog.v1.ServerHeader
- metadata_ - Variable in class io.grpc.binarylog.v1.Trailer.Builder
- metadata_ - Variable in class io.grpc.binarylog.v1.Trailer
- METADATA_FIELD_NUMBER - Static variable in class io.grpc.binarylog.v1.ClientHeader
- METADATA_FIELD_NUMBER - Static variable in class io.grpc.binarylog.v1.ServerHeader
- METADATA_FIELD_NUMBER - Static variable in class io.grpc.binarylog.v1.Trailer
- Metadata.AsciiKey<T> - Class in io.grpc
- Metadata.AsciiMarshaller<T> - Interface in io.grpc
-
Marshaller for metadata values that are serialized into ASCII strings.
- Metadata.BinaryKey<T> - Class in io.grpc
- Metadata.BinaryMarshaller<T> - Interface in io.grpc
-
Marshaller for metadata values that are serialized into raw binary.
- Metadata.BinaryStreamMarshaller<T> - Interface in io.grpc
-
Marshaller for metadata values that are serialized to an InputStream.
- Metadata.Builder - Class in io.grpc.binarylog.v1
-
A list of metadata pairs, used in the payload of client header, server header, and server trailer.
- Metadata.IterableAt<T> - Class in io.grpc
- Metadata.Key<T> - Class in io.grpc
-
Key for metadata entries.
- Metadata.LazyStreamBinaryKey<T> - Class in io.grpc
-
A binary key for values which should be serialized lazily to
InputStream
s. - Metadata.LazyValue<T> - Class in io.grpc
-
Internal holder for values which are serialized/de-serialized lazily.
- Metadata.TrustedAsciiKey<T> - Class in io.grpc
- Metadata.TrustedAsciiMarshaller<T> - Interface in io.grpc
-
A specialized plain ASCII marshaller.
- MetadataApplier() - Constructor for class io.grpc.CallCredentials.MetadataApplier
- MetadataApplierImpl - Class in io.grpc.internal
- MetadataApplierImpl(ClientTransport, MethodDescriptor<?, ?>, Metadata, CallOptions, MetadataApplierImpl.MetadataApplierListener, ClientStreamTracer[]) - Constructor for class io.grpc.internal.MetadataApplierImpl
- MetadataApplierImpl.MetadataApplierListener - Interface in io.grpc.internal
- MetadataAttachingServerCall(ServerCall<ReqT, RespT>) - Constructor for class io.grpc.stub.MetadataUtils.MetadataAttachingServerInterceptor.MetadataAttachingServerCall
- MetadataAttachingServerInterceptor(Metadata) - Constructor for class io.grpc.stub.MetadataUtils.MetadataAttachingServerInterceptor
- metadataBuilder_ - Variable in class io.grpc.binarylog.v1.ClientHeader.Builder
- metadataBuilder_ - Variable in class io.grpc.binarylog.v1.ServerHeader.Builder
- metadataBuilder_ - Variable in class io.grpc.binarylog.v1.Trailer.Builder
- MetadataCapturingClientCall(ClientCall<ReqT, RespT>) - Constructor for class io.grpc.stub.MetadataUtils.MetadataCapturingClientInterceptor.MetadataCapturingClientCall
- MetadataCapturingClientCallListener(ClientCall.Listener<RespT>) - Constructor for class io.grpc.stub.MetadataUtils.MetadataCapturingClientInterceptor.MetadataCapturingClientCall.MetadataCapturingClientCallListener
- MetadataCapturingClientInterceptor(AtomicReference<Metadata>, AtomicReference<Metadata>) - Constructor for class io.grpc.stub.MetadataUtils.MetadataCapturingClientInterceptor
- MetadataEntry - Class in io.grpc.binarylog.v1
-
A metadata key value pair
- MetadataEntry() - Constructor for class io.grpc.binarylog.v1.MetadataEntry
- MetadataEntry(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.binarylog.v1.MetadataEntry
- MetadataEntry.Builder - Class in io.grpc.binarylog.v1
-
A metadata key value pair
- MetadataEntryOrBuilder - Interface in io.grpc.binarylog.v1
- metadataMarshaller(T) - Static method in class io.grpc.protobuf.lite.ProtoLiteUtils
-
Produce a metadata marshaller for a protobuf type.
- metadataMarshaller(T) - Static method in class io.grpc.protobuf.ProtoUtils
-
Produce a metadata marshaller for a protobuf type.
- MetadataMarshaller(T) - Constructor for class io.grpc.protobuf.lite.ProtoLiteUtils.MetadataMarshaller
- MetadataOrBuilder - Interface in io.grpc.binarylog.v1
- metadataSize(Metadata) - Static method in class io.grpc.inprocess.InProcessTransport
- MetadataUtils - Class in io.grpc.stub
-
Utility functions for binding and receiving headers.
- MetadataUtils() - Constructor for class io.grpc.stub.MetadataUtils
- MetadataUtils.HeaderAttachingClientInterceptor - Class in io.grpc.stub
- MetadataUtils.HeaderAttachingClientInterceptor.HeaderAttachingClientCall<ReqT,
RespT> - Class in io.grpc.stub - MetadataUtils.MetadataAttachingServerInterceptor - Class in io.grpc.stub
- MetadataUtils.MetadataAttachingServerInterceptor.MetadataAttachingServerCall<ReqT,
RespT> - Class in io.grpc.stub - MetadataUtils.MetadataCapturingClientInterceptor - Class in io.grpc.stub
- MetadataUtils.MetadataCapturingClientInterceptor.MetadataCapturingClientCall<ReqT,
RespT> - Class in io.grpc.stub - MetadataUtils.MetadataCapturingClientInterceptor.MetadataCapturingClientCall.MetadataCapturingClientCallListener - Class in io.grpc.stub
- method - Variable in class io.grpc.inprocess.InProcessTransport.InProcessStream
- method - Variable in class io.grpc.internal.ClientCallImpl
- method - Variable in class io.grpc.internal.ManagedChannelImpl.ConfigSelectingClientCall
- method - Variable in class io.grpc.internal.ManagedChannelImpl.RealChannel.PendingCall
- method - Variable in class io.grpc.internal.MetadataApplierImpl
- method - Variable in class io.grpc.internal.PickSubchannelArgsImpl
- method - Variable in class io.grpc.internal.RetriableStream
- method - Variable in class io.grpc.internal.ServerCallImpl
- method - Variable in class io.grpc.netty.GrpcHttp2HeadersUtils.GrpcHttp2RequestHeaders
- method - Variable in class io.grpc.netty.NettyClientStream
- method - Variable in class io.grpc.rls.AutoValue_RlsProtoData_ExtraKeys
- method - Variable in class io.grpc.rls.AutoValue_RlsProtoData_GrpcKeyBuilder_Name
- method - Variable in class io.grpc.ServerMethodDefinition
- method - Variable in class io.grpc.stub.ServerCalls.StreamingServerCallHandler
- method - Variable in class io.grpc.stub.ServerCalls.UnaryServerCallHandler
- method() - Method in class io.grpc.netty.AbstractHttp2Headers
- method() - Method in class io.grpc.netty.GrpcHttp2HeadersUtils.GrpcHttp2RequestHeaders
- method() - Method in class io.grpc.rls.AutoValue_RlsProtoData_ExtraKeys
- method() - Method in class io.grpc.rls.AutoValue_RlsProtoData_GrpcKeyBuilder_Name
- method() - Method in class io.grpc.rls.RlsProtoData.ExtraKeys
- method() - Method in class io.grpc.rls.RlsProtoData.GrpcKeyBuilder.Name
- method(CharSequence) - Method in class io.grpc.netty.AbstractHttp2Headers
- method_ - Variable in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys.Builder
- method_ - Variable in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys
- method_ - Variable in class io.grpc.lookup.v1.GrpcKeyBuilder.Name.Builder
- method_ - Variable in class io.grpc.lookup.v1.GrpcKeyBuilder.Name
- METHOD_FIELD_NUMBER - Static variable in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys
- METHOD_FIELD_NUMBER - Static variable in class io.grpc.lookup.v1.GrpcKeyBuilder.Name
- METHOD_HEADER - Static variable in class io.grpc.netty.GrpcHttp2HeadersUtils.GrpcHttp2RequestHeaders
- METHOD_NAME_FIELD_NUMBER - Static variable in class io.grpc.binarylog.v1.ClientHeader
- methodDescriptor - Variable in class io.grpc.internal.ServerCallInfoImpl
- MethodDescriptor<ReqT,
RespT> - Class in io.grpc -
Description of a remote method used by
Channel
to initiate a call. - MethodDescriptor(MethodDescriptor.MethodType, String, MethodDescriptor.Marshaller<ReqT>, MethodDescriptor.Marshaller<RespT>, Object, boolean, boolean, boolean) - Constructor for class io.grpc.MethodDescriptor
- MethodDescriptor.Builder<ReqT,
RespT> - Class in io.grpc -
A builder for a
MethodDescriptor
. - 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 its type parameter
T
at runtime. - methodDescriptorAccessor - Static variable in class io.grpc.netty.NettyClientStream
- MethodHandlers(ChannelzGrpc.AsyncService, int) - Constructor for class io.grpc.channelz.v1.ChannelzGrpc.MethodHandlers
- MethodHandlers(HealthGrpc.AsyncService, int) - Constructor for class io.grpc.health.v1.HealthGrpc.MethodHandlers
- MethodHandlers(LoadBalancerGrpc.AsyncService, int) - Constructor for class io.grpc.lb.v1.LoadBalancerGrpc.MethodHandlers
- MethodHandlers(RouteLookupServiceGrpc.AsyncService, int) - Constructor for class io.grpc.lookup.v1.RouteLookupServiceGrpc.MethodHandlers
- MethodHandlers(ServerReflectionGrpc.AsyncService, int) - Constructor for class io.grpc.reflection.v1.ServerReflectionGrpc.MethodHandlers
- MethodHandlers(ServerReflectionGrpc.AsyncService, int) - Constructor for class io.grpc.reflection.v1alpha.ServerReflectionGrpc.MethodHandlers
- methodId - Variable in class io.grpc.channelz.v1.ChannelzGrpc.MethodHandlers
- methodId - Variable in class io.grpc.health.v1.HealthGrpc.MethodHandlers
- methodId - Variable in class io.grpc.lb.v1.LoadBalancerGrpc.MethodHandlers
- methodId - Variable in class io.grpc.lookup.v1.RouteLookupServiceGrpc.MethodHandlers
- methodId - Variable in class io.grpc.reflection.v1.ServerReflectionGrpc.MethodHandlers
- methodId - Variable in class io.grpc.reflection.v1alpha.ServerReflectionGrpc.MethodHandlers
- METHODID_BALANCE_LOAD - Static variable in class io.grpc.lb.v1.LoadBalancerGrpc
- METHODID_CHECK - Static variable in class io.grpc.health.v1.HealthGrpc
- METHODID_GET_CHANNEL - Static variable in class io.grpc.channelz.v1.ChannelzGrpc
- METHODID_GET_SERVER - Static variable in class io.grpc.channelz.v1.ChannelzGrpc
- METHODID_GET_SERVER_SOCKETS - Static variable in class io.grpc.channelz.v1.ChannelzGrpc
- METHODID_GET_SERVERS - Static variable in class io.grpc.channelz.v1.ChannelzGrpc
- METHODID_GET_SOCKET - Static variable in class io.grpc.channelz.v1.ChannelzGrpc
- METHODID_GET_SUBCHANNEL - Static variable in class io.grpc.channelz.v1.ChannelzGrpc
- METHODID_GET_TOP_CHANNELS - Static variable in class io.grpc.channelz.v1.ChannelzGrpc
- METHODID_ROUTE_LOOKUP - Static variable in class io.grpc.lookup.v1.RouteLookupServiceGrpc
- METHODID_SERVER_REFLECTION_INFO - Static variable in class io.grpc.reflection.v1.ServerReflectionGrpc
- METHODID_SERVER_REFLECTION_INFO - Static variable in class io.grpc.reflection.v1alpha.ServerReflectionGrpc
- METHODID_WATCH - Static variable in class io.grpc.health.v1.HealthGrpc
- MethodInfo(Map<String, ?>, boolean, int, int) - Constructor for class io.grpc.internal.ManagedChannelServiceConfig.MethodInfo
-
Constructor.
- methodName - Variable in class io.grpc.channelz.v1.ChannelzGrpc.ChannelzMethodDescriptorSupplier
- methodName - Variable in class io.grpc.health.v1.HealthGrpc.HealthMethodDescriptorSupplier
- methodName - Variable in class io.grpc.lb.v1.LoadBalancerGrpc.LoadBalancerMethodDescriptorSupplier
- methodName - Variable in class io.grpc.lookup.v1.RouteLookupServiceGrpc.RouteLookupServiceMethodDescriptorSupplier
- methodName - Variable in class io.grpc.netty.NettyClientStream.TransportState
- methodName - Variable in class io.grpc.reflection.v1.ServerReflectionGrpc.ServerReflectionMethodDescriptorSupplier
- methodName - Variable in class io.grpc.reflection.v1alpha.ServerReflectionGrpc.ServerReflectionMethodDescriptorSupplier
- methodName_ - Variable in class io.grpc.binarylog.v1.ClientHeader.Builder
- methodName_ - Variable in class io.grpc.binarylog.v1.ClientHeader
- methods - Variable in class io.grpc.internal.InternalHandlerRegistry
- methods - Variable in class io.grpc.ServerServiceDefinition.Builder
- methods - Variable in class io.grpc.ServerServiceDefinition
- methods - Variable in class io.grpc.ServiceDescriptor.Builder
- methods - Variable in class io.grpc.ServiceDescriptor
- methodType() - Element in annotation type io.grpc.stub.annotations.RpcMethod
-
The call type of the method.
- MethodType() - Constructor for enum io.grpc.MethodDescriptor.MethodType
- MetricInstrument - Interface in io.grpc
-
Represents a metric instrument.
- MetricInstrumentRegistry - Class in io.grpc
-
A registry for globally registered metric instruments.
- MetricInstrumentRegistry() - Constructor for class io.grpc.MetricInstrumentRegistry
- metricInstruments - Variable in class io.grpc.MetricInstrumentRegistry
- metricRecorder - Variable in class io.grpc.internal.ManagedChannelImpl
- MetricRecorder - Class in io.grpc.services
-
Implements the service/APIs for Out-of-Band metrics reporting, only for utilization metrics.
- MetricRecorder - Interface in io.grpc
-
An interface used for recording gRPC metrics.
- MetricRecorder() - Constructor for class io.grpc.services.MetricRecorder
- MetricRecorder.BatchCallback - Interface in io.grpc
-
Callback to record gauge values.
- MetricRecorder.BatchRecorder - Interface in io.grpc
-
Recorder for instrument values produced by a batch callback.
- MetricRecorder.Registration - Interface in io.grpc
-
A handle to a registration, that allows unregistration.
- MetricRecorderHelper - Class in io.grpc.services
-
Utility helper class to check whether values for
CallMetricRecorder
andMetricRecorder
are inside the valid range. - MetricRecorderHelper() - Constructor for class io.grpc.services.MetricRecorderHelper
- MetricRecorderImpl - Class in io.grpc.internal
-
Provides a central point for gRPC components to record metric values.
- MetricRecorderImpl(List<MetricSink>, MetricInstrumentRegistry) - Constructor for class io.grpc.internal.MetricRecorderImpl
- MetricRecorderImpl.BatchRecorderImpl - Class in io.grpc.internal
-
Recorder for instrument values produced by a batch callback.
- MetricReport - Class in io.grpc.services
-
A gRPC object of orca load report.
- MetricReport(double, double, double, double, double, Map<String, Double>, Map<String, Double>, Map<String, Double>) - Constructor for class io.grpc.services.MetricReport
- metricsData - Variable in class io.grpc.services.MetricRecorder
- MetricSink - Interface in io.grpc
-
An internal interface representing a receiver or aggregator of gRPC metrics data.
- MetricSink.Registration - Interface in io.grpc
- metricSinks - Variable in class io.grpc.internal.ManagedChannelImplBuilder
- metricSinks - Variable in class io.grpc.internal.MetricRecorderImpl
- metricsInstanceUuid - Variable in class io.grpc.rls.CachingRlsLbClient
- MigratingDeframerListener(MessageDeframer.Listener) - Constructor for class io.grpc.internal.MigratingThreadDeframer.MigratingDeframerListener
- migratingListener - Variable in class io.grpc.internal.MigratingThreadDeframer
- MigratingThreadDeframer - Class in io.grpc.internal
-
A deframer that moves decoding between the transport and app threads based on which is more efficient at that moment.
- MigratingThreadDeframer(MessageDeframer.Listener, ApplicationThreadDeframerListener.TransportExecutor, MessageDeframer) - Constructor for class io.grpc.internal.MigratingThreadDeframer
- MigratingThreadDeframer.DeframeMessageProducer - Class in io.grpc.internal
- MigratingThreadDeframer.MigratingDeframerListener - Class in io.grpc.internal
- MigratingThreadDeframer.Op - Interface in io.grpc.internal
- min(Deadline, Deadline) - Static method in class io.grpc.internal.ClientCallImpl
- min(Deadline, Deadline) - Static method in class io.grpc.protobuf.services.BinlogHelper
- MIN_BUFFER - Static variable in class io.grpc.netty.NettyWritableBufferAllocator
- MIN_EVICTION_TIME_DELTA_NANOS - Static variable in class io.grpc.rls.CachingRlsLbClient
- MIN_KEEPALIVE_TIME_NANOS - Static variable in class io.grpc.internal.KeepAliveManager
- MIN_KEEPALIVE_TIMEOUT_NANOS - Static variable in class io.grpc.internal.KeepAliveManager
- MIN_MAX_CONNECTION_AGE_NANO - Static variable in class io.grpc.netty.NettyServerBuilder
- MIN_MAX_CONNECTION_IDLE_NANO - Static variable in class io.grpc.netty.NettyServerBuilder
- MIN_OFFSET - Static variable in class io.grpc.Deadline
- minEvictionTime - Variable in class io.grpc.rls.CachingRlsLbClient.DataCacheEntry
- minimum(Deadline) - Method in class io.grpc.Deadline
-
Return the minimum deadline of
this
or an other deadline. - MINIMUM_REFRESH_PERIOD_IN_MINUTES - Static variable in class io.grpc.util.AdvancedTlsX509KeyManager
- MINIMUM_REFRESH_PERIOD_IN_MINUTES - Static variable in class io.grpc.util.AdvancedTlsX509TrustManager
- minimumHosts - Variable in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig.FailurePercentageEjection.Builder
- minimumHosts - Variable in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig.FailurePercentageEjection
- minimumHosts - Variable in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig.SuccessRateEjection.Builder
- minimumHosts - Variable in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig.SuccessRateEjection
- minTimeNanos - Variable in class io.grpc.internal.KeepAliveEnforcer
- MISCARRIED - Enum constant in enum io.grpc.internal.ClientStreamListener.RpcProgress
-
The stream is closed even before anything leaves the client.
- MISSING_REQUEST - Static variable in class io.grpc.stub.ServerCalls
- MISSING_RESPONSE - Static variable in class io.grpc.internal.ServerCallImpl
- missingCallSite - Static variable in class io.grpc.internal.ManagedChannelOrphanWrapper.ManagedChannelReference
- missingCallSite() - Static method in class io.grpc.internal.ManagedChannelOrphanWrapper.ManagedChannelReference
- mode - Variable in class io.grpc.grpclb.GrpclbConfig
- Mode() - Constructor for enum io.grpc.grpclb.GrpclbState.Mode
- model_ - Variable in class io.grpc.channelz.v1.Security.Builder
- model_ - Variable in class io.grpc.channelz.v1.Security
- MODEL_NOT_SET - Enum constant in enum io.grpc.channelz.v1.Security.ModelCase
- ModelCase(int) - Constructor for enum io.grpc.channelz.v1.Security.ModelCase
- modelCase_ - Variable in class io.grpc.channelz.v1.Security.Builder
- modelCase_ - Variable in class io.grpc.channelz.v1.Security
- msg - Variable in class io.grpc.netty.WriteBufferingAndExceptionHandler.ChannelWrite
- MTLS - Enum constant in enum io.grpc.TlsChannelCredentials.Feature
-
Client identity may be provided and server verification can be tuned.
- MTLS - Enum constant in enum io.grpc.TlsServerCredentials.Feature
-
Client certificates may be requested and verified.
- MultiChildLoadBalancer - Class in io.grpc.util
-
A base load balancing policy for those policies which has multiple children such as ClusterManager or the petiole policies.
- MultiChildLoadBalancer(LoadBalancer.Helper) - Constructor for class io.grpc.util.MultiChildLoadBalancer
- MultiChildLoadBalancer.AcceptResolvedAddrRetVal - Class in io.grpc.util
- MultiChildLoadBalancer.ChildLbState - Class in io.grpc.util
-
This represents the state of load balancer children.
- MultiChildLoadBalancer.ChildLbState.ChildLbStateHelper - Class in io.grpc.util
-
ChildLbStateHelper is the glue between ChildLbState and the helpers associated with the petiole policy above and the PickFirstLoadBalancer's helper below.
- MultiChildLoadBalancer.Endpoint - Class in io.grpc.util
-
Endpoint is an optimization to quickly lookup and compare EquivalentAddressGroup address sets.
- multiplier - Variable in class io.grpc.internal.ExponentialBackoffPolicy
- MutableHandlerRegistry - Class in io.grpc.util
-
Default implementation of
HandlerRegistry
. - MutableHandlerRegistry() - Constructor for class io.grpc.util.MutableHandlerRegistry
- mutableServicesIndex - Variable in class io.grpc.protobuf.services.ProtoReflectionServiceV1.ServerReflectionIndex
N
- name - Variable in class io.grpc.Context.Key
- name - Variable in class io.grpc.inprocess.InProcessSocketAddress
- name - Variable in class io.grpc.internal.AtomicBackoff
- name - Variable in class io.grpc.InternalChannelz.OtherSecurity
- name - Variable in class io.grpc.Metadata.Key
- name - Variable in class io.grpc.netty.Utils.DefaultEventLoopGroupResource
- name - Variable in class io.grpc.PartialMetricInstrument
- name - Variable in class io.grpc.ServiceDescriptor.Builder
- name - Variable in class io.grpc.ServiceDescriptor
- name() - Method in class io.grpc.Metadata.Key
-
Returns the normalized name for this key.
- name(int) - Method in class io.grpc.Metadata
- name(int, byte[]) - Method in class io.grpc.Metadata
- Name() - Constructor for class io.grpc.lookup.v1.GrpcKeyBuilder.Name
- Name() - Constructor for class io.grpc.rls.RlsProtoData.GrpcKeyBuilder.Name
- Name(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.lookup.v1.GrpcKeyBuilder.Name
- name_ - Variable in class io.grpc.channelz.v1.Address.OtherAddress.Builder
- name_ - Variable in class io.grpc.channelz.v1.Address.OtherAddress
- name_ - Variable in class io.grpc.channelz.v1.ChannelRef.Builder
- name_ - Variable in class io.grpc.channelz.v1.ChannelRef
- name_ - Variable in class io.grpc.channelz.v1.Security.OtherSecurity.Builder
- name_ - Variable in class io.grpc.channelz.v1.Security.OtherSecurity
- name_ - Variable in class io.grpc.channelz.v1.ServerRef.Builder
- name_ - Variable in class io.grpc.channelz.v1.ServerRef
- name_ - Variable in class io.grpc.channelz.v1.SocketOption.Builder
- name_ - Variable in class io.grpc.channelz.v1.SocketOption
- name_ - Variable in class io.grpc.channelz.v1.SocketRef.Builder
- name_ - Variable in class io.grpc.channelz.v1.SocketRef
- name_ - Variable in class io.grpc.channelz.v1.SubchannelRef.Builder
- name_ - Variable in class io.grpc.channelz.v1.SubchannelRef
- name_ - Variable in class io.grpc.lb.v1.InitialLoadBalanceRequest.Builder
- name_ - Variable in class io.grpc.lb.v1.InitialLoadBalanceRequest
- name_ - Variable in class io.grpc.reflection.v1.ServiceResponse.Builder
- name_ - Variable in class io.grpc.reflection.v1.ServiceResponse
- name_ - Variable in class io.grpc.reflection.v1alpha.ServiceResponse.Builder
- name_ - Variable in class io.grpc.reflection.v1alpha.ServiceResponse
- NAME_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.Address.OtherAddress
- NAME_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.ChannelRef
- NAME_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.Security.OtherSecurity
- NAME_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.ServerRef
- NAME_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.SocketOption
- NAME_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.SocketRef
- NAME_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.SubchannelRef
- NAME_FIELD_NUMBER - Static variable in class io.grpc.lb.v1.InitialLoadBalanceRequest
- NAME_FIELD_NUMBER - Static variable in class io.grpc.reflection.v1.ServiceResponse
- NAME_FIELD_NUMBER - Static variable in class io.grpc.reflection.v1alpha.ServiceResponse
- NAME_RESOLUTION_DELAYED - Static variable in class io.grpc.ClientStreamTracer
-
Indicates how long the call was delayed, in nanoseconds, due to waiting for name resolution result.
- nameBytes - Variable in class io.grpc.Metadata.Key
- namedMetrics - Variable in class io.grpc.services.CallMetricRecorder
- namedMetrics - Variable in class io.grpc.services.MetricReport
- NameMatcher - Class in io.grpc.lookup.v1
-
Extract a key based on a given name (e.g.
- NameMatcher() - Constructor for class io.grpc.lookup.v1.NameMatcher
- NameMatcher() - Constructor for class io.grpc.rls.RlsProtoData.NameMatcher
- NameMatcher(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.lookup.v1.NameMatcher
- NameMatcher.Builder - Class in io.grpc.lookup.v1
-
Extract a key based on a given name (e.g.
- NameMatcherOrBuilder - Interface in io.grpc.lookup.v1
- nameResolver - Variable in class io.grpc.internal.ManagedChannelImpl
- NameResolver - Class in io.grpc
-
A pluggable component that resolves a target
URI
and return addresses to the caller. - NameResolver() - Constructor for class io.grpc.NameResolver
- NameResolver.Args - Class in io.grpc
-
Information that a
NameResolver.Factory
uses to create aNameResolver
. - NameResolver.Args.Builder - Class in io.grpc
-
Builder for
NameResolver.Args
. - NameResolver.ConfigOrError - Class in io.grpc
-
Represents either a successfully parsed service config, containing all necessary parts to be later applied by the channel, or a Status containing the error encountered while parsing.
- NameResolver.Factory - Class in io.grpc
-
Factory that creates
NameResolver
instances. - NameResolver.Listener - Interface in io.grpc
-
Receives address updates.
- NameResolver.Listener2 - Class in io.grpc
-
Receives address updates.
- NameResolver.ResolutionResult - Class in io.grpc
-
Represents the results from a Name Resolver.
- NameResolver.ResolutionResult.Builder - Class in io.grpc
-
A builder for
NameResolver.ResolutionResult
. - NameResolver.ResolutionResultAttr - Annotation Type in io.grpc
-
Annotation for name resolution result attributes.
- NameResolver.ServiceConfigParser - Class in io.grpc
-
Parses and validates service configuration.
- nameResolverArgs - Variable in class io.grpc.internal.ManagedChannelImpl
- nameResolverFactory(NameResolver.Factory) - Method in class io.grpc.ForwardingChannelBuilder
-
Deprecated.
- nameResolverFactory(NameResolver.Factory) - Method in class io.grpc.ForwardingChannelBuilder2
-
Deprecated.
- nameResolverFactory(NameResolver.Factory) - Method in class io.grpc.internal.ManagedChannelImplBuilder
-
Deprecated.
- nameResolverFactory(NameResolver.Factory) - Method in class io.grpc.ManagedChannelBuilder
-
Deprecated.Most usages should use a globally-registered
NameResolverProvider
instead, with either the SPI mechanism orNameResolverRegistry.register(io.grpc.NameResolverProvider)
. Replacements for all use-cases are not necessarily available yet. See #7133. - NameResolverFactory() - Constructor for class io.grpc.NameResolverRegistry.NameResolverFactory
- NameResolverFactoryToProviderFacade - Class in io.grpc.internal
- NameResolverFactoryToProviderFacade(NameResolver.Factory) - Constructor for class io.grpc.internal.NameResolverFactoryToProviderFacade
- NameResolverListener(ManagedChannelImpl.LbHelperImpl, NameResolver) - Constructor for class io.grpc.internal.ManagedChannelImpl.NameResolverListener
- NameResolverPriorityAccessor() - Constructor for class io.grpc.NameResolverRegistry.NameResolverPriorityAccessor
- nameResolverProvider - Variable in class io.grpc.internal.ManagedChannelImpl
- NameResolverProvider - Class in io.grpc
-
Provider of name resolvers for name agnostic consumption.
- NameResolverProvider() - Constructor for class io.grpc.NameResolverProvider
- nameResolverRegistry - Variable in class io.grpc.internal.ManagedChannelImpl
- nameResolverRegistry - Variable in class io.grpc.internal.ManagedChannelImplBuilder
- nameResolverRegistry(NameResolverRegistry) - Method in class io.grpc.internal.ManagedChannelImplBuilder
- NameResolverRegistry - Class in io.grpc
-
Registry of
NameResolverProvider
s. - NameResolverRegistry() - Constructor for class io.grpc.NameResolverRegistry
- NameResolverRegistry.NameResolverFactory - Class in io.grpc
- NameResolverRegistry.NameResolverPriorityAccessor - Class in io.grpc
- nameResolverStarted - Variable in class io.grpc.internal.ManagedChannelImpl
- names - Variable in class io.grpc.rls.AutoValue_RlsProtoData_GrpcKeyBuilder
- names - Variable in class io.grpc.rls.AutoValue_RlsProtoData_NameMatcher
- names() - Method in class io.grpc.netty.AbstractHttp2Headers
- names() - Method in class io.grpc.rls.AutoValue_RlsProtoData_GrpcKeyBuilder
- names() - Method in class io.grpc.rls.AutoValue_RlsProtoData_NameMatcher
- names() - Method in class io.grpc.rls.RlsProtoData.GrpcKeyBuilder
-
Returns names.
- names() - Method in class io.grpc.rls.RlsProtoData.NameMatcher
-
Returns ordered list of names; the first non-empty value will be used.
- names_ - Variable in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
- names_ - Variable in class io.grpc.lookup.v1.GrpcKeyBuilder
- names_ - Variable in class io.grpc.lookup.v1.NameMatcher.Builder
- names_ - Variable in class io.grpc.lookup.v1.NameMatcher
- NAMES_FIELD_NUMBER - Static variable in class io.grpc.lookup.v1.GrpcKeyBuilder
- NAMES_FIELD_NUMBER - Static variable in class io.grpc.lookup.v1.NameMatcher
- namesAndValues - Variable in class io.grpc.Metadata
- namesAndValues - Variable in class io.grpc.netty.GrpcHttp2HeadersUtils.GrpcHttp2InboundHeaders
- namesAndValues() - Method in class io.grpc.netty.GrpcHttp2HeadersUtils.GrpcHttp2InboundHeaders
-
Returns the header names and values as bytes.
- namesAndValuesIdx - Variable in class io.grpc.netty.GrpcHttp2HeadersUtils.GrpcHttp2InboundHeaders
- namesAndValuesToImmutableList() - Method in class io.grpc.netty.GrpcHttp2HeadersUtils.GrpcHttp2InboundHeaders
- namesAndValuesToString() - Method in class io.grpc.netty.GrpcHttp2HeadersUtils.GrpcHttp2InboundHeaders
- namesBuilder_ - Variable in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
- NANO_TO_SECS - Static variable in class io.grpc.internal.ClientCallImpl
- NANOS_PER_SECOND - Static variable in class io.grpc.Deadline
- NANOS_PER_SECOND - Static variable in class io.grpc.internal.JsonUtil
- nanoTime() - Method in class io.grpc.Deadline.SystemTicker
- nanoTime() - Method in class io.grpc.Deadline.Ticker
-
Returns the number of nanoseconds since this source's epoch.
- nanoTime() - Method in class io.grpc.internal.KeepAliveEnforcer.SystemTicker
- nanoTime() - Method in interface io.grpc.internal.KeepAliveEnforcer.Ticker
- nanoTime() - Method in interface io.grpc.internal.MaxConnectionIdleManager.Ticker
- nanoTime() - Method in class io.grpc.internal.Rescheduler
- NativeSocketOptions(InternalChannelz.TcpInfo, Map<String, String>) - Constructor for class io.grpc.netty.NettySocketSupport.NativeSocketOptions
-
Creates an instance.
- negotiationAttributes - Variable in class io.grpc.netty.NettyServerHandler
-
Incomplete attributes produced by negotiator.
- negotiationLogger - Variable in class io.grpc.netty.GrpcHttp2ConnectionHandler
- negotiationLogger - Variable in class io.grpc.netty.ProtocolNegotiators.Http2UpgradeAndGrpcHandler
- negotiationLogger - Variable in class io.grpc.netty.ProtocolNegotiators.ProtocolNegotiationHandler
- negotiationScheme - Variable in class io.grpc.netty.NettyClientTransport
- negotiationType - Variable in class io.grpc.netty.NettyChannelBuilder.DefaultProtocolNegotiator
- negotiationType(NegotiationType) - Method in class io.grpc.netty.NettyChannelBuilder
-
Sets the negotiation type for the HTTP/2 connection.
- NegotiationType - Enum in io.grpc.netty
-
Identifies the negotiation used for starting up HTTP/2.
- NegotiationType() - Constructor for enum io.grpc.netty.NegotiationType
- negotiator - Variable in class io.grpc.netty.InternalProtocolNegotiator.ProtocolNegotiatorAdapter
- negotiator - Variable in class io.grpc.netty.NettyChannelCredentials
- negotiator - Variable in class io.grpc.netty.NettyClientTransport
- negotiator - Variable in class io.grpc.netty.NettyServerCredentials
- negotiator - Variable in class io.grpc.netty.ProtocolNegotiators.FromChannelCredentialsResult
- negotiator - Variable in class io.grpc.netty.ProtocolNegotiators.FromServerCredentialsResult
- negotiator(ProtocolNegotiator.ClientFactory) - Static method in class io.grpc.netty.ProtocolNegotiators.FromChannelCredentialsResult
- negotiator(ProtocolNegotiator.ServerFactory) - Static method in class io.grpc.netty.ProtocolNegotiators.FromServerCredentialsResult
- negotiatorName - Variable in class io.grpc.netty.ProtocolNegotiators.ProtocolNegotiationHandler
- NETTY - Enum constant in enum io.grpc.InternalKnownTransport
- NETTY_SHADED - Enum constant in enum io.grpc.InternalKnownTransport
- NettyAdaptiveCumulator - Class in io.grpc.netty
-
"Adaptive" cumulator: cumulate
ByteBuf
s by dynamically switching between merge and compose strategies. - NettyAdaptiveCumulator(int) - Constructor for class io.grpc.netty.NettyAdaptiveCumulator
-
"Adaptive" cumulator: cumulate
ByteBuf
s by dynamically switching between merge and compose strategies. - NettyChannelBuilder - Class in io.grpc.netty
-
A builder to help simplify construction of channels using the Netty transport.
- NettyChannelBuilder(String) - Constructor for class io.grpc.netty.NettyChannelBuilder
- NettyChannelBuilder(String, ChannelCredentials, CallCredentials, ProtocolNegotiator.ClientFactory) - Constructor for class io.grpc.netty.NettyChannelBuilder
- NettyChannelBuilder(SocketAddress) - Constructor for class io.grpc.netty.NettyChannelBuilder
- NettyChannelBuilder(SocketAddress, ChannelCredentials, CallCredentials, ProtocolNegotiator.ClientFactory) - Constructor for class io.grpc.netty.NettyChannelBuilder
- NettyChannelBuilder.DefaultProtocolNegotiator - Class in io.grpc.netty
- NettyChannelBuilder.LocalSocketPicker - Class in io.grpc.netty
-
This class is meant to be overriden with a custom implementation of
NettyChannelBuilder.LocalSocketPicker.createSocketAddress(java.net.SocketAddress, io.grpc.Attributes)
. - NettyChannelBuilder.NettyChannelDefaultPortProvider - Class in io.grpc.netty
- NettyChannelBuilder.NettyChannelTransportFactoryBuilder - Class in io.grpc.netty
- NettyChannelBuilder.NettyTransportFactory - Class in io.grpc.netty
-
Creates Netty transports.
- NettyChannelCredentials - Class in io.grpc.netty
-
A credential with full control over the security handshake.
- NettyChannelCredentials(ProtocolNegotiator.ClientFactory) - Constructor for class io.grpc.netty.NettyChannelCredentials
- NettyChannelDefaultPortProvider() - Constructor for class io.grpc.netty.NettyChannelBuilder.NettyChannelDefaultPortProvider
- NettyChannelProvider - Class in io.grpc.netty
-
Provider for
NettyChannelBuilder
instances. - NettyChannelProvider() - Constructor for class io.grpc.netty.NettyChannelProvider
- NettyChannelTransportFactoryBuilder() - Constructor for class io.grpc.netty.NettyChannelBuilder.NettyChannelTransportFactoryBuilder
- NettyClientHandler - Class in io.grpc.netty
-
Client-side Netty handler for GRPC processing.
- NettyClientHandler(Http2ConnectionDecoder, Http2ConnectionEncoder, Http2Settings, ChannelLogger, ClientTransportLifecycleManager, KeepAliveManager, Supplier<Stopwatch>, Runnable, TransportTracer, Attributes, String, boolean, AbstractNettyHandler.PingLimiter, Ticker) - Constructor for class io.grpc.netty.NettyClientHandler
- NettyClientHandler.FrameListener - Class in io.grpc.netty
- NettyClientHandler.PingCountingFrameWriter - Class in io.grpc.netty
- NettyClientStream - Class in io.grpc.netty
-
Client stream for a Netty transport.
- NettyClientStream(NettyClientStream.TransportState, MethodDescriptor<?, ?>, Metadata, Channel, AsciiString, AsciiString, AsciiString, StatsTraceContext, TransportTracer, CallOptions, boolean) - Constructor for class io.grpc.netty.NettyClientStream
- NettyClientStream.Sink - Class in io.grpc.netty
- NettyClientStream.TransportState - Class in io.grpc.netty
-
This should only be called from the transport thread.
- NettyClientTransport - Class in io.grpc.netty
-
A Netty-based
ConnectionClientTransport
implementation. - NettyClientTransport(SocketAddress, ChannelFactory<? extends Channel>, Map<ChannelOption<?>, ?>, EventLoopGroup, ProtocolNegotiator, boolean, int, int, int, long, long, boolean, String, String, Runnable, TransportTracer, Attributes, NettyChannelBuilder.LocalSocketPicker, ChannelLogger, boolean, Ticker) - Constructor for class io.grpc.netty.NettyClientTransport
- NettyClientTransportServersBuilder() - Constructor for class io.grpc.netty.NettyServerBuilder.NettyClientTransportServersBuilder
- NettyReadableBuffer - Class in io.grpc.netty
-
A
Buffer
implementation that is backed by a NettyByteBuf
. - NettyReadableBuffer(ByteBuf) - Constructor for class io.grpc.netty.NettyReadableBuffer
- NettyServer - Class in io.grpc.netty
-
Netty-based server implementation.
- NettyServer(List<? extends SocketAddress>, ChannelFactory<? extends ServerChannel>, Map<ChannelOption<?>, ?>, Map<ChannelOption<?>, ?>, ObjectPool<? extends EventLoopGroup>, ObjectPool<? extends EventLoopGroup>, boolean, ProtocolNegotiator, List<? extends ServerStreamTracer.Factory>, TransportTracer.Factory, int, boolean, int, int, int, long, long, long, long, long, boolean, long, int, long, Attributes, InternalChannelz) - Constructor for class io.grpc.netty.NettyServer
- NettyServer.ListenSocket - Class in io.grpc.netty
-
A class that can answer channelz queries about the server listen sockets.
- NettyServer.SharedResourceReferenceCounter - Class in io.grpc.netty
- NettyServerBuilder - Class in io.grpc.netty
-
A builder to help simplify the construction of a Netty-based GRPC server.
- NettyServerBuilder(SocketAddress) - Constructor for class io.grpc.netty.NettyServerBuilder
- NettyServerBuilder(SocketAddress, ProtocolNegotiator.ServerFactory) - Constructor for class io.grpc.netty.NettyServerBuilder
- NettyServerBuilder.NettyClientTransportServersBuilder - Class in io.grpc.netty
- NettyServerCredentials - Class in io.grpc.netty
-
A credential with full control over the security handshake.
- NettyServerCredentials(ProtocolNegotiator.ServerFactory) - Constructor for class io.grpc.netty.NettyServerCredentials
- NettyServerHandler - Class in io.grpc.netty
-
Server-side Netty handler for GRPC processing.
- NettyServerHandler(ChannelPromise, Http2Connection, ServerTransportListener, List<? extends ServerStreamTracer.Factory>, TransportTracer, Http2ConnectionDecoder, Http2ConnectionEncoder, Http2Settings, int, long, long, long, long, long, KeepAliveEnforcer, boolean, int, long, Attributes, Ticker) - Constructor for class io.grpc.netty.NettyServerHandler
- NettyServerHandler.FrameListener - Class in io.grpc.netty
- NettyServerHandler.GracefulShutdown - Class in io.grpc.netty
- NettyServerHandler.KeepAlivePinger - Class in io.grpc.netty
- NettyServerHandler.ServerChannelLogger - Class in io.grpc.netty
- NettyServerHandler.WriteMonitoringFrameWriter - Class in io.grpc.netty
- NettyServerProvider - Class in io.grpc.netty
-
Provider for
NettyServerBuilder
instances. - NettyServerProvider() - Constructor for class io.grpc.netty.NettyServerProvider
- NettyServerStream - Class in io.grpc.netty
-
Server stream for a Netty HTTP2 transport.
- NettyServerStream(Channel, NettyServerStream.TransportState, Attributes, String, StatsTraceContext) - Constructor for class io.grpc.netty.NettyServerStream
- NettyServerStream.Sink - Class in io.grpc.netty
- NettyServerStream.TransportState - Class in io.grpc.netty
-
This should only be called from the transport thread.
- NettyServerTransport - Class in io.grpc.netty
-
The Netty-based server transport.
- NettyServerTransport(Channel, ChannelPromise, ProtocolNegotiator, List<? extends ServerStreamTracer.Factory>, TransportTracer, int, boolean, int, int, int, long, long, long, long, long, boolean, long, int, long, Attributes) - Constructor for class io.grpc.netty.NettyServerTransport
- NettySocketHelperImpl() - Constructor for class io.grpc.netty.NettySocketSupport.NettySocketHelperImpl
- NettySocketSupport - Class in io.grpc.netty
-
An class for getting low level socket info.
- NettySocketSupport() - Constructor for class io.grpc.netty.NettySocketSupport
- NettySocketSupport.Helper - Interface in io.grpc.netty
- NettySocketSupport.NativeSocketOptions - Class in io.grpc.netty
-
A TcpInfo and additional other info that will be turned into channelz socket options.
- NettySocketSupport.NettySocketHelperImpl - Class in io.grpc.netty
- NettySslContextChannelCredentials - Class in io.grpc.netty
-
A credential that performs TLS with Netty's SslContext as configuration.
- NettySslContextChannelCredentials() - Constructor for class io.grpc.netty.NettySslContextChannelCredentials
- NettySslContextServerCredentials - Class in io.grpc.netty
-
A credential that performs TLS with Netty's SslContext as configuration.
- NettySslContextServerCredentials() - Constructor for class io.grpc.netty.NettySslContextServerCredentials
- NettyTransportFactory(ProtocolNegotiator, ChannelFactory<? extends Channel>, Map<ChannelOption<?>, ?>, ObjectPool<? extends EventLoopGroup>, boolean, int, int, int, long, long, boolean, TransportTracer.Factory, NettyChannelBuilder.LocalSocketPicker, boolean, Class<? extends SocketAddress>) - Constructor for class io.grpc.netty.NettyChannelBuilder.NettyTransportFactory
- NettyWritableBuffer - Class in io.grpc.netty
-
The
WritableBuffer
used by the Netty transport. - NettyWritableBuffer(ByteBuf) - Constructor for class io.grpc.netty.NettyWritableBuffer
- NettyWritableBufferAllocator - Class in io.grpc.netty
-
The default allocator for
NettyWritableBuffer
s used by the Netty transport. - NettyWritableBufferAllocator(ByteBufAllocator) - Constructor for class io.grpc.netty.NettyWritableBufferAllocator
- NETWORKADDRESS_CACHE_TTL_PROPERTY - Static variable in class io.grpc.internal.DnsNameResolver
-
Java networking system properties name for caching DNS result.
- NEVER_INCLUDED_METADATA - Static variable in class io.grpc.protobuf.services.BinlogHelper
- NEW_PROVIDER_METHOD - Static variable in class io.grpc.internal.ConscryptLoader
- newAttachHeadersInterceptor(Metadata) - Static method in class io.grpc.stub.MetadataUtils
-
Returns a client interceptor that attaches a set of headers to requests.
- newAttachMetadataServerInterceptor(Metadata) - Static method in class io.grpc.stub.MetadataUtils
-
Returns a ServerInterceptor that adds the specified Metadata to every response stream, one way or another.
- newBlockingStub(Channel) - Static method in class io.grpc.channelz.v1.ChannelzGrpc
-
Creates a new blocking-style stub that supports unary and streaming output calls on the service
- newBlockingStub(Channel) - Static method in class io.grpc.health.v1.HealthGrpc
-
Creates a new blocking-style stub that supports unary and streaming output calls on the service
- newBlockingStub(Channel) - Static method in class io.grpc.lb.v1.LoadBalancerGrpc
-
Creates a new blocking-style stub that supports unary and streaming output calls on the service
- newBlockingStub(Channel) - Static method in class io.grpc.lookup.v1.RouteLookupServiceGrpc
-
Creates a new blocking-style stub that supports unary and streaming output calls on the service
- newBlockingStub(Channel) - Static method in class io.grpc.reflection.v1.ServerReflectionGrpc
-
Creates a new blocking-style stub that supports unary and streaming output calls on the service
- newBlockingStub(Channel) - Static method in class io.grpc.reflection.v1alpha.ServerReflectionGrpc
-
Creates a new blocking-style stub that supports unary and streaming output calls on the service
- newBuilder() - Static method in class io.grpc.Attributes
-
Create a new builder.
- newBuilder() - Static method in class io.grpc.binarylog.v1.Address
- newBuilder() - Static method in class io.grpc.binarylog.v1.ClientHeader
- newBuilder() - Static method in class io.grpc.binarylog.v1.GrpcLogEntry
- newBuilder() - Static method in class io.grpc.binarylog.v1.Message
- newBuilder() - Static method in class io.grpc.binarylog.v1.Metadata
- newBuilder() - Static method in class io.grpc.binarylog.v1.MetadataEntry
- newBuilder() - Static method in class io.grpc.binarylog.v1.ServerHeader
- newBuilder() - Static method in class io.grpc.binarylog.v1.Trailer
- newBuilder() - Static method in class io.grpc.channelz.v1.Address
- newBuilder() - Static method in class io.grpc.channelz.v1.Address.OtherAddress
- newBuilder() - Static method in class io.grpc.channelz.v1.Address.TcpIpAddress
- newBuilder() - Static method in class io.grpc.channelz.v1.Address.UdsAddress
- newBuilder() - Static method in class io.grpc.channelz.v1.Channel
- newBuilder() - Static method in class io.grpc.channelz.v1.ChannelConnectivityState
- newBuilder() - Static method in class io.grpc.channelz.v1.ChannelData
- newBuilder() - Static method in class io.grpc.channelz.v1.ChannelRef
- newBuilder() - Static method in class io.grpc.channelz.v1.ChannelTrace
- newBuilder() - Static method in class io.grpc.channelz.v1.ChannelTraceEvent
- newBuilder() - Static method in class io.grpc.channelz.v1.GetChannelRequest
- newBuilder() - Static method in class io.grpc.channelz.v1.GetChannelResponse
- newBuilder() - Static method in class io.grpc.channelz.v1.GetServerRequest
- newBuilder() - Static method in class io.grpc.channelz.v1.GetServerResponse
- newBuilder() - Static method in class io.grpc.channelz.v1.GetServerSocketsRequest
- newBuilder() - Static method in class io.grpc.channelz.v1.GetServerSocketsResponse
- newBuilder() - Static method in class io.grpc.channelz.v1.GetServersRequest
- newBuilder() - Static method in class io.grpc.channelz.v1.GetServersResponse
- newBuilder() - Static method in class io.grpc.channelz.v1.GetSocketRequest
- newBuilder() - Static method in class io.grpc.channelz.v1.GetSocketResponse
- newBuilder() - Static method in class io.grpc.channelz.v1.GetSubchannelRequest
- newBuilder() - Static method in class io.grpc.channelz.v1.GetSubchannelResponse
- newBuilder() - Static method in class io.grpc.channelz.v1.GetTopChannelsRequest
- newBuilder() - Static method in class io.grpc.channelz.v1.GetTopChannelsResponse
- newBuilder() - Static method in class io.grpc.channelz.v1.Security
- newBuilder() - Static method in class io.grpc.channelz.v1.Security.OtherSecurity
- newBuilder() - Static method in class io.grpc.channelz.v1.Security.Tls
- newBuilder() - Static method in class io.grpc.channelz.v1.Server
- newBuilder() - Static method in class io.grpc.channelz.v1.ServerData
- newBuilder() - Static method in class io.grpc.channelz.v1.ServerRef
- newBuilder() - Static method in class io.grpc.channelz.v1.Socket
- newBuilder() - Static method in class io.grpc.channelz.v1.SocketData
- newBuilder() - Static method in class io.grpc.channelz.v1.SocketOption
- newBuilder() - Static method in class io.grpc.channelz.v1.SocketOptionLinger
- newBuilder() - Static method in class io.grpc.channelz.v1.SocketOptionTcpInfo
- newBuilder() - Static method in class io.grpc.channelz.v1.SocketOptionTimeout
- newBuilder() - Static method in class io.grpc.channelz.v1.SocketRef
- newBuilder() - Static method in class io.grpc.channelz.v1.Subchannel
- newBuilder() - Static method in class io.grpc.channelz.v1.SubchannelRef
- newBuilder() - Static method in class io.grpc.ClientStreamTracer.StreamInfo
-
Creates an empty Builder.
- newBuilder() - Static method in class io.grpc.health.v1.HealthCheckRequest
- newBuilder() - Static method in class io.grpc.health.v1.HealthCheckResponse
- newBuilder() - Static method in class io.grpc.HttpConnectProxiedSocketAddress
-
Create a new builder.
- newBuilder() - Static method in class io.grpc.InternalConfigSelector.Result
- newBuilder() - Static method in class io.grpc.lb.v1.ClientStats
- newBuilder() - Static method in class io.grpc.lb.v1.ClientStatsPerToken
- newBuilder() - Static method in class io.grpc.lb.v1.FallbackResponse
- newBuilder() - Static method in class io.grpc.lb.v1.InitialLoadBalanceRequest
- newBuilder() - Static method in class io.grpc.lb.v1.InitialLoadBalanceResponse
- newBuilder() - Static method in class io.grpc.lb.v1.LoadBalanceRequest
- newBuilder() - Static method in class io.grpc.lb.v1.LoadBalanceResponse
- newBuilder() - Static method in class io.grpc.lb.v1.Server
- newBuilder() - Static method in class io.grpc.lb.v1.ServerList
- newBuilder() - Static method in class io.grpc.LoadBalancer.CreateSubchannelArgs
-
Creates a new builder.
- newBuilder() - Static method in class io.grpc.LoadBalancer.ResolvedAddresses
-
Factory for constructing a new Builder.
- newBuilder() - Static method in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys
- newBuilder() - Static method in class io.grpc.lookup.v1.GrpcKeyBuilder.Name
- newBuilder() - Static method in class io.grpc.lookup.v1.GrpcKeyBuilder
- newBuilder() - Static method in class io.grpc.lookup.v1.HttpKeyBuilder
- newBuilder() - Static method in class io.grpc.lookup.v1.NameMatcher
- newBuilder() - Static method in class io.grpc.lookup.v1.RouteLookupClusterSpecifier
- newBuilder() - Static method in class io.grpc.lookup.v1.RouteLookupConfig
- newBuilder() - Static method in class io.grpc.lookup.v1.RouteLookupRequest
- newBuilder() - Static method in class io.grpc.lookup.v1.RouteLookupResponse
- newBuilder() - Static method in class io.grpc.MethodDescriptor
-
Creates a new builder for a
MethodDescriptor
. - newBuilder() - Static method in class io.grpc.NameResolver.Args
-
Creates a new builder.
- newBuilder() - Static method in class io.grpc.NameResolver.ResolutionResult
-
Constructs a new builder of a name resolution result.
- newBuilder() - Static method in class io.grpc.reflection.v1.ErrorResponse
- newBuilder() - Static method in class io.grpc.reflection.v1.ExtensionNumberResponse
- newBuilder() - Static method in class io.grpc.reflection.v1.ExtensionRequest
- newBuilder() - Static method in class io.grpc.reflection.v1.FileDescriptorResponse
- newBuilder() - Static method in class io.grpc.reflection.v1.ListServiceResponse
- newBuilder() - Static method in class io.grpc.reflection.v1.ServerReflectionRequest
- newBuilder() - Static method in class io.grpc.reflection.v1.ServerReflectionResponse
- newBuilder() - Static method in class io.grpc.reflection.v1.ServiceResponse
- newBuilder() - Static method in class io.grpc.reflection.v1alpha.ErrorResponse
- newBuilder() - Static method in class io.grpc.reflection.v1alpha.ExtensionNumberResponse
- newBuilder() - Static method in class io.grpc.reflection.v1alpha.ExtensionRequest
- newBuilder() - Static method in class io.grpc.reflection.v1alpha.FileDescriptorResponse
- newBuilder() - Static method in class io.grpc.reflection.v1alpha.ListServiceResponse
- newBuilder() - Static method in class io.grpc.reflection.v1alpha.ServerReflectionRequest
- newBuilder() - Static method in class io.grpc.reflection.v1alpha.ServerReflectionResponse
- newBuilder() - Static method in class io.grpc.reflection.v1alpha.ServiceResponse
- newBuilder() - Static method in class io.grpc.rls.CachingRlsLbClient
-
Returns a Builder for
CachingRlsLbClient
. - newBuilder() - Static method in class io.grpc.TlsChannelCredentials
-
Creates a builder for changing default configuration.
- newBuilder() - Static method in class io.grpc.TlsServerCredentials
-
Creates a builder for changing default configuration.
- newBuilder() - Static method in class io.grpc.util.AdvancedTlsX509TrustManager
- newBuilder(Attributes) - Static method in class io.grpc.Attributes
-
Deprecated.Use
Attributes.toBuilder()
on theAttributes
instance instead. This method will be removed in the future. - newBuilder(Address) - Static method in class io.grpc.binarylog.v1.Address
- newBuilder(ClientHeader) - Static method in class io.grpc.binarylog.v1.ClientHeader
- newBuilder(GrpcLogEntry) - Static method in class io.grpc.binarylog.v1.GrpcLogEntry
- newBuilder(Message) - Static method in class io.grpc.binarylog.v1.Message
- newBuilder(Metadata) - Static method in class io.grpc.binarylog.v1.Metadata
- newBuilder(MetadataEntry) - Static method in class io.grpc.binarylog.v1.MetadataEntry
- newBuilder(ServerHeader) - Static method in class io.grpc.binarylog.v1.ServerHeader
- newBuilder(Trailer) - Static method in class io.grpc.binarylog.v1.Trailer
- newBuilder(Address) - Static method in class io.grpc.channelz.v1.Address
- newBuilder(Address.OtherAddress) - Static method in class io.grpc.channelz.v1.Address.OtherAddress
- newBuilder(Address.TcpIpAddress) - Static method in class io.grpc.channelz.v1.Address.TcpIpAddress
- newBuilder(Address.UdsAddress) - Static method in class io.grpc.channelz.v1.Address.UdsAddress
- newBuilder(Channel) - Static method in class io.grpc.channelz.v1.Channel
- newBuilder(ChannelConnectivityState) - Static method in class io.grpc.channelz.v1.ChannelConnectivityState
- newBuilder(ChannelData) - Static method in class io.grpc.channelz.v1.ChannelData
- newBuilder(ChannelRef) - Static method in class io.grpc.channelz.v1.ChannelRef
- newBuilder(ChannelTrace) - Static method in class io.grpc.channelz.v1.ChannelTrace
- newBuilder(ChannelTraceEvent) - Static method in class io.grpc.channelz.v1.ChannelTraceEvent
- newBuilder(GetChannelRequest) - Static method in class io.grpc.channelz.v1.GetChannelRequest
- newBuilder(GetChannelResponse) - Static method in class io.grpc.channelz.v1.GetChannelResponse
- newBuilder(GetServerRequest) - Static method in class io.grpc.channelz.v1.GetServerRequest
- newBuilder(GetServerResponse) - Static method in class io.grpc.channelz.v1.GetServerResponse
- newBuilder(GetServerSocketsRequest) - Static method in class io.grpc.channelz.v1.GetServerSocketsRequest
- newBuilder(GetServerSocketsResponse) - Static method in class io.grpc.channelz.v1.GetServerSocketsResponse
- newBuilder(GetServersRequest) - Static method in class io.grpc.channelz.v1.GetServersRequest
- newBuilder(GetServersResponse) - Static method in class io.grpc.channelz.v1.GetServersResponse
- newBuilder(GetSocketRequest) - Static method in class io.grpc.channelz.v1.GetSocketRequest
- newBuilder(GetSocketResponse) - Static method in class io.grpc.channelz.v1.GetSocketResponse
- newBuilder(GetSubchannelRequest) - Static method in class io.grpc.channelz.v1.GetSubchannelRequest
- newBuilder(GetSubchannelResponse) - Static method in class io.grpc.channelz.v1.GetSubchannelResponse
- newBuilder(GetTopChannelsRequest) - Static method in class io.grpc.channelz.v1.GetTopChannelsRequest
- newBuilder(GetTopChannelsResponse) - Static method in class io.grpc.channelz.v1.GetTopChannelsResponse
- newBuilder(Security) - Static method in class io.grpc.channelz.v1.Security
- newBuilder(Security.OtherSecurity) - Static method in class io.grpc.channelz.v1.Security.OtherSecurity
- newBuilder(Security.Tls) - Static method in class io.grpc.channelz.v1.Security.Tls
- newBuilder(Server) - Static method in class io.grpc.channelz.v1.Server
- newBuilder(ServerData) - Static method in class io.grpc.channelz.v1.ServerData
- newBuilder(ServerRef) - Static method in class io.grpc.channelz.v1.ServerRef
- newBuilder(Socket) - Static method in class io.grpc.channelz.v1.Socket
- newBuilder(SocketData) - Static method in class io.grpc.channelz.v1.SocketData
- newBuilder(SocketOption) - Static method in class io.grpc.channelz.v1.SocketOption
- newBuilder(SocketOptionLinger) - Static method in class io.grpc.channelz.v1.SocketOptionLinger
- newBuilder(SocketOptionTcpInfo) - Static method in class io.grpc.channelz.v1.SocketOptionTcpInfo
- newBuilder(SocketOptionTimeout) - Static method in class io.grpc.channelz.v1.SocketOptionTimeout
- newBuilder(SocketRef) - Static method in class io.grpc.channelz.v1.SocketRef
- newBuilder(Subchannel) - Static method in class io.grpc.channelz.v1.Subchannel
- newBuilder(SubchannelRef) - Static method in class io.grpc.channelz.v1.SubchannelRef
- newBuilder(HealthCheckRequest) - Static method in class io.grpc.health.v1.HealthCheckRequest
- newBuilder(HealthCheckResponse) - Static method in class io.grpc.health.v1.HealthCheckResponse
- newBuilder(ClientStats) - Static method in class io.grpc.lb.v1.ClientStats
- newBuilder(ClientStatsPerToken) - Static method in class io.grpc.lb.v1.ClientStatsPerToken
- newBuilder(FallbackResponse) - Static method in class io.grpc.lb.v1.FallbackResponse
- newBuilder(InitialLoadBalanceRequest) - Static method in class io.grpc.lb.v1.InitialLoadBalanceRequest
- newBuilder(InitialLoadBalanceResponse) - Static method in class io.grpc.lb.v1.InitialLoadBalanceResponse
- newBuilder(LoadBalanceRequest) - Static method in class io.grpc.lb.v1.LoadBalanceRequest
- newBuilder(LoadBalanceResponse) - Static method in class io.grpc.lb.v1.LoadBalanceResponse
- newBuilder(Server) - Static method in class io.grpc.lb.v1.Server
- newBuilder(ServerList) - Static method in class io.grpc.lb.v1.ServerList
- newBuilder(GrpcKeyBuilder) - Static method in class io.grpc.lookup.v1.GrpcKeyBuilder
- newBuilder(GrpcKeyBuilder.ExtraKeys) - Static method in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys
- newBuilder(GrpcKeyBuilder.Name) - Static method in class io.grpc.lookup.v1.GrpcKeyBuilder.Name
- newBuilder(HttpKeyBuilder) - Static method in class io.grpc.lookup.v1.HttpKeyBuilder
- newBuilder(NameMatcher) - Static method in class io.grpc.lookup.v1.NameMatcher
- newBuilder(RouteLookupClusterSpecifier) - Static method in class io.grpc.lookup.v1.RouteLookupClusterSpecifier
- newBuilder(RouteLookupConfig) - Static method in class io.grpc.lookup.v1.RouteLookupConfig
- newBuilder(RouteLookupRequest) - Static method in class io.grpc.lookup.v1.RouteLookupRequest
- newBuilder(RouteLookupResponse) - Static method in class io.grpc.lookup.v1.RouteLookupResponse
- newBuilder(MethodDescriptor.Marshaller<ReqT>, MethodDescriptor.Marshaller<RespT>) - Static method in class io.grpc.MethodDescriptor
-
Creates a new builder for a
MethodDescriptor
. - newBuilder(ErrorResponse) - Static method in class io.grpc.reflection.v1.ErrorResponse
- newBuilder(ExtensionNumberResponse) - Static method in class io.grpc.reflection.v1.ExtensionNumberResponse
- newBuilder(ExtensionRequest) - Static method in class io.grpc.reflection.v1.ExtensionRequest
- newBuilder(FileDescriptorResponse) - Static method in class io.grpc.reflection.v1.FileDescriptorResponse
- newBuilder(ListServiceResponse) - Static method in class io.grpc.reflection.v1.ListServiceResponse
- newBuilder(ServerReflectionRequest) - Static method in class io.grpc.reflection.v1.ServerReflectionRequest
- newBuilder(ServerReflectionResponse) - Static method in class io.grpc.reflection.v1.ServerReflectionResponse
- newBuilder(ServiceResponse) - Static method in class io.grpc.reflection.v1.ServiceResponse
- newBuilder(ErrorResponse) - Static method in class io.grpc.reflection.v1alpha.ErrorResponse
- newBuilder(ExtensionNumberResponse) - Static method in class io.grpc.reflection.v1alpha.ExtensionNumberResponse
- newBuilder(ExtensionRequest) - Static method in class io.grpc.reflection.v1alpha.ExtensionRequest
- newBuilder(FileDescriptorResponse) - Static method in class io.grpc.reflection.v1alpha.FileDescriptorResponse
- newBuilder(ListServiceResponse) - Static method in class io.grpc.reflection.v1alpha.ListServiceResponse
- newBuilder(ServerReflectionRequest) - Static method in class io.grpc.reflection.v1alpha.ServerReflectionRequest
- newBuilder(ServerReflectionResponse) - Static method in class io.grpc.reflection.v1alpha.ServerReflectionResponse
- newBuilder(ServiceResponse) - Static method in class io.grpc.reflection.v1alpha.ServiceResponse
- newBuilder(String) - Static method in class io.grpc.ServiceDescriptor
-
Creates a new builder for a
ServiceDescriptor
. - newBuilderForType() - Method in class io.grpc.binarylog.v1.Address
- newBuilderForType() - Method in class io.grpc.binarylog.v1.ClientHeader
- newBuilderForType() - Method in class io.grpc.binarylog.v1.GrpcLogEntry
- newBuilderForType() - Method in class io.grpc.binarylog.v1.Message
- newBuilderForType() - Method in class io.grpc.binarylog.v1.Metadata
- newBuilderForType() - Method in class io.grpc.binarylog.v1.MetadataEntry
- newBuilderForType() - Method in class io.grpc.binarylog.v1.ServerHeader
- newBuilderForType() - Method in class io.grpc.binarylog.v1.Trailer
- newBuilderForType() - Method in class io.grpc.channelz.v1.Address
- newBuilderForType() - Method in class io.grpc.channelz.v1.Address.OtherAddress
- newBuilderForType() - Method in class io.grpc.channelz.v1.Address.TcpIpAddress
- newBuilderForType() - Method in class io.grpc.channelz.v1.Address.UdsAddress
- newBuilderForType() - Method in class io.grpc.channelz.v1.Channel
- newBuilderForType() - Method in class io.grpc.channelz.v1.ChannelConnectivityState
- newBuilderForType() - Method in class io.grpc.channelz.v1.ChannelData
- newBuilderForType() - Method in class io.grpc.channelz.v1.ChannelRef
- newBuilderForType() - Method in class io.grpc.channelz.v1.ChannelTrace
- newBuilderForType() - Method in class io.grpc.channelz.v1.ChannelTraceEvent
- newBuilderForType() - Method in class io.grpc.channelz.v1.GetChannelRequest
- newBuilderForType() - Method in class io.grpc.channelz.v1.GetChannelResponse
- newBuilderForType() - Method in class io.grpc.channelz.v1.GetServerRequest
- newBuilderForType() - Method in class io.grpc.channelz.v1.GetServerResponse
- newBuilderForType() - Method in class io.grpc.channelz.v1.GetServerSocketsRequest
- newBuilderForType() - Method in class io.grpc.channelz.v1.GetServerSocketsResponse
- newBuilderForType() - Method in class io.grpc.channelz.v1.GetServersRequest
- newBuilderForType() - Method in class io.grpc.channelz.v1.GetServersResponse
- newBuilderForType() - Method in class io.grpc.channelz.v1.GetSocketRequest
- newBuilderForType() - Method in class io.grpc.channelz.v1.GetSocketResponse
- newBuilderForType() - Method in class io.grpc.channelz.v1.GetSubchannelRequest
- newBuilderForType() - Method in class io.grpc.channelz.v1.GetSubchannelResponse
- newBuilderForType() - Method in class io.grpc.channelz.v1.GetTopChannelsRequest
- newBuilderForType() - Method in class io.grpc.channelz.v1.GetTopChannelsResponse
- newBuilderForType() - Method in class io.grpc.channelz.v1.Security
- newBuilderForType() - Method in class io.grpc.channelz.v1.Security.OtherSecurity
- newBuilderForType() - Method in class io.grpc.channelz.v1.Security.Tls
- newBuilderForType() - Method in class io.grpc.channelz.v1.Server
- newBuilderForType() - Method in class io.grpc.channelz.v1.ServerData
- newBuilderForType() - Method in class io.grpc.channelz.v1.ServerRef
- newBuilderForType() - Method in class io.grpc.channelz.v1.Socket
- newBuilderForType() - Method in class io.grpc.channelz.v1.SocketData
- newBuilderForType() - Method in class io.grpc.channelz.v1.SocketOption
- newBuilderForType() - Method in class io.grpc.channelz.v1.SocketOptionLinger
- newBuilderForType() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo
- newBuilderForType() - Method in class io.grpc.channelz.v1.SocketOptionTimeout
- newBuilderForType() - Method in class io.grpc.channelz.v1.SocketRef
- newBuilderForType() - Method in class io.grpc.channelz.v1.Subchannel
- newBuilderForType() - Method in class io.grpc.channelz.v1.SubchannelRef
- newBuilderForType() - Method in class io.grpc.health.v1.HealthCheckRequest
- newBuilderForType() - Method in class io.grpc.health.v1.HealthCheckResponse
- newBuilderForType() - Method in class io.grpc.lb.v1.ClientStats
- newBuilderForType() - Method in class io.grpc.lb.v1.ClientStatsPerToken
- newBuilderForType() - Method in class io.grpc.lb.v1.FallbackResponse
- newBuilderForType() - Method in class io.grpc.lb.v1.InitialLoadBalanceRequest
- newBuilderForType() - Method in class io.grpc.lb.v1.InitialLoadBalanceResponse
- newBuilderForType() - Method in class io.grpc.lb.v1.LoadBalanceRequest
- newBuilderForType() - Method in class io.grpc.lb.v1.LoadBalanceResponse
- newBuilderForType() - Method in class io.grpc.lb.v1.Server
- newBuilderForType() - Method in class io.grpc.lb.v1.ServerList
- newBuilderForType() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys
- newBuilderForType() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Name
- newBuilderForType() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder
- newBuilderForType() - Method in class io.grpc.lookup.v1.HttpKeyBuilder
- newBuilderForType() - Method in class io.grpc.lookup.v1.NameMatcher
- newBuilderForType() - Method in class io.grpc.lookup.v1.RouteLookupClusterSpecifier
- newBuilderForType() - Method in class io.grpc.lookup.v1.RouteLookupConfig
- newBuilderForType() - Method in class io.grpc.lookup.v1.RouteLookupRequest
- newBuilderForType() - Method in class io.grpc.lookup.v1.RouteLookupResponse
- newBuilderForType() - Method in class io.grpc.reflection.v1.ErrorResponse
- newBuilderForType() - Method in class io.grpc.reflection.v1.ExtensionNumberResponse
- newBuilderForType() - Method in class io.grpc.reflection.v1.ExtensionRequest
- newBuilderForType() - Method in class io.grpc.reflection.v1.FileDescriptorResponse
- newBuilderForType() - Method in class io.grpc.reflection.v1.ListServiceResponse
- newBuilderForType() - Method in class io.grpc.reflection.v1.ServerReflectionRequest
- newBuilderForType() - Method in class io.grpc.reflection.v1.ServerReflectionResponse
- newBuilderForType() - Method in class io.grpc.reflection.v1.ServiceResponse
- newBuilderForType() - Method in class io.grpc.reflection.v1alpha.ErrorResponse
- newBuilderForType() - Method in class io.grpc.reflection.v1alpha.ExtensionNumberResponse
- newBuilderForType() - Method in class io.grpc.reflection.v1alpha.ExtensionRequest
- newBuilderForType() - Method in class io.grpc.reflection.v1alpha.FileDescriptorResponse
- newBuilderForType() - Method in class io.grpc.reflection.v1alpha.ListServiceResponse
- newBuilderForType() - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest
- newBuilderForType() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse
- newBuilderForType() - Method in class io.grpc.reflection.v1alpha.ServiceResponse
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.binarylog.v1.Address
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.binarylog.v1.ClientHeader
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.binarylog.v1.GrpcLogEntry
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.binarylog.v1.Message
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.binarylog.v1.Metadata
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.binarylog.v1.MetadataEntry
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.binarylog.v1.ServerHeader
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.binarylog.v1.Trailer
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.channelz.v1.Address
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.channelz.v1.Address.OtherAddress
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.channelz.v1.Address.TcpIpAddress
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.channelz.v1.Address.UdsAddress
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.channelz.v1.Channel
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.channelz.v1.ChannelConnectivityState
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.channelz.v1.ChannelData
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.channelz.v1.ChannelRef
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.channelz.v1.ChannelTrace
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.channelz.v1.ChannelTraceEvent
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.channelz.v1.GetChannelRequest
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.channelz.v1.GetChannelResponse
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.channelz.v1.GetServerRequest
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.channelz.v1.GetServerResponse
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.channelz.v1.GetServerSocketsRequest
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.channelz.v1.GetServerSocketsResponse
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.channelz.v1.GetServersRequest
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.channelz.v1.GetServersResponse
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.channelz.v1.GetSocketRequest
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.channelz.v1.GetSocketResponse
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.channelz.v1.GetSubchannelRequest
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.channelz.v1.GetSubchannelResponse
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.channelz.v1.GetTopChannelsRequest
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.channelz.v1.GetTopChannelsResponse
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.channelz.v1.Security
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.channelz.v1.Security.OtherSecurity
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.channelz.v1.Security.Tls
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.channelz.v1.Server
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.channelz.v1.ServerData
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.channelz.v1.ServerRef
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.channelz.v1.Socket
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.channelz.v1.SocketData
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.channelz.v1.SocketOption
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.channelz.v1.SocketOptionLinger
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.channelz.v1.SocketOptionTimeout
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.channelz.v1.SocketRef
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.channelz.v1.Subchannel
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.channelz.v1.SubchannelRef
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.health.v1.HealthCheckRequest
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.health.v1.HealthCheckResponse
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.lb.v1.ClientStats
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.lb.v1.ClientStatsPerToken
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.lb.v1.FallbackResponse
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.lb.v1.InitialLoadBalanceRequest
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.lb.v1.InitialLoadBalanceResponse
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.lb.v1.LoadBalanceRequest
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.lb.v1.LoadBalanceResponse
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.lb.v1.Server
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.lb.v1.ServerList
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Name
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.lookup.v1.HttpKeyBuilder
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.lookup.v1.NameMatcher
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.lookup.v1.RouteLookupClusterSpecifier
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.lookup.v1.RouteLookupConfig
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.lookup.v1.RouteLookupRequest
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.lookup.v1.RouteLookupResponse
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.reflection.v1.ErrorResponse
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.reflection.v1.ExtensionNumberResponse
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.reflection.v1.ExtensionRequest
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.reflection.v1.FileDescriptorResponse
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.reflection.v1.ListServiceResponse
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.reflection.v1.ServerReflectionRequest
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.reflection.v1.ServerReflectionResponse
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.reflection.v1.ServiceResponse
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.reflection.v1alpha.ErrorResponse
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.reflection.v1alpha.ExtensionNumberResponse
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.reflection.v1alpha.ExtensionRequest
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.reflection.v1alpha.FileDescriptorResponse
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.reflection.v1alpha.ListServiceResponse
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse
- newBuilderForType(AbstractMessage.BuilderParent) - Method in class io.grpc.reflection.v1alpha.ServiceResponse
- newCall(MethodDescriptor<ReqT, RespT>, CallOptions) - Method in class io.grpc.ClientInterceptors.InterceptorChannel
- newCall(MethodDescriptor<ReqT, RespT>, CallOptions) - Method in class io.grpc.internal.ManagedChannelImpl
- newCall(MethodDescriptor<ReqT, RespT>, CallOptions) - Method in class io.grpc.internal.ManagedChannelImpl.RealChannel
- newCall(MethodDescriptor<RequestT, ResponseT>, CallOptions) - Method in class io.grpc.Channel
-
Create a
ClientCall
to the remote operation specified by the givenMethodDescriptor
. - newCall(MethodDescriptor<RequestT, ResponseT>, CallOptions) - Method in class io.grpc.internal.ForwardingManagedChannel
- newCall(MethodDescriptor<RequestT, ResponseT>, CallOptions) - Method in class io.grpc.internal.OobChannel
- newCall(MethodDescriptor<RequestT, ResponseT>, CallOptions) - Method in class io.grpc.internal.SubchannelChannel
- newCallMetricRecorder() - Static method in class io.grpc.services.InternalCallMetricRecorder
- newCaptureMetadataInterceptor(AtomicReference<Metadata>, AtomicReference<Metadata>) - Static method in class io.grpc.stub.MetadataUtils
-
Captures the last received metadata on a channel.
- newChannelBuilder(ManagedChannelProvider, String, ChannelCredentials) - Static method in class io.grpc.InternalManagedChannelProvider
- newChannelBuilder(NameResolverRegistry, String, ChannelCredentials) - Method in class io.grpc.ManagedChannelRegistry
- newChannelBuilder(String, ChannelCredentials) - Static method in class io.grpc.Grpc
-
Creates a channel builder with a target string and credentials.
- newChannelBuilder(String, ChannelCredentials) - Method in class io.grpc.ManagedChannelProvider
-
Creates a new builder with the given target URI and credentials.
- newChannelBuilder(String, ChannelCredentials) - Method in class io.grpc.ManagedChannelRegistry
- newChannelBuilder(String, ChannelCredentials) - Method in class io.grpc.netty.NettyChannelProvider
- newChannelBuilder(String, ChannelCredentials) - Method in class io.grpc.netty.UdsNettyChannelProvider
- newChannelBuilderForAddress(String, int, ChannelCredentials) - Static method in class io.grpc.Grpc
-
Creates a channel builder from a host, port, and credentials.
- NewChannelBuilderResult(ManagedChannelBuilder<?>, String) - Constructor for class io.grpc.ManagedChannelProvider.NewChannelBuilderResult
- newClientCall(MethodDescriptor<ReqT, RespT>, CallOptions) - Method in class io.grpc.internal.ManagedChannelImpl.RealChannel
- newClientContext(ClientStreamTracer[], Attributes, Metadata) - Static method in class io.grpc.internal.StatsTraceContext
-
Factory method for the client-side.
- newClientStreamTracer(ClientStreamTracer.StreamInfo, Metadata) - Method in class io.grpc.ClientStreamTracer.Factory
-
Creates a
ClientStreamTracer
for a new client stream. - newClientStreamTracer(ClientStreamTracer.StreamInfo, Metadata) - Method in class io.grpc.grpclb.GrpclbClientLoadRecorder
- newClientStreamTracer(ClientStreamTracer.StreamInfo, Metadata) - Method in class io.grpc.grpclb.TokenAttachingTracerFactory
- newClientStreamTracer(ClientStreamTracer.StreamInfo, Metadata) - Method in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionPicker.ResultCountingClientStreamTracerFactory
- newClientTransport(SocketAddress, ClientTransportFactory.ClientTransportOptions, ChannelLogger) - Method in class io.grpc.inprocess.InProcessChannelBuilder.InProcessClientTransportFactory
- newClientTransport(SocketAddress, ClientTransportFactory.ClientTransportOptions, ChannelLogger) - Method in class io.grpc.internal.CallCredentialsApplyingTransportFactory
- newClientTransport(SocketAddress, ClientTransportFactory.ClientTransportOptions, ChannelLogger) - Method in interface io.grpc.internal.ClientTransportFactory
-
Creates an unstarted transport for exclusive use.
- newClientTransport(SocketAddress, ClientTransportFactory.ClientTransportOptions, ChannelLogger) - Method in class io.grpc.netty.NettyChannelBuilder.NettyTransportFactory
- newdata - Variable in class io.grpc.Attributes.Builder
- newEmptyInstance() - Static method in class io.grpc.CompressorRegistry
-
Returns a new instance with no registered compressors.
- newFutureStub(Channel) - Static method in class io.grpc.channelz.v1.ChannelzGrpc
-
Creates a new ListenableFuture-style stub that supports unary calls on the service
- newFutureStub(Channel) - Static method in class io.grpc.health.v1.HealthGrpc
-
Creates a new ListenableFuture-style stub that supports unary calls on the service
- newFutureStub(Channel) - Static method in class io.grpc.lb.v1.LoadBalancerGrpc
-
Creates a new ListenableFuture-style stub that supports unary calls on the service
- newFutureStub(Channel) - Static method in class io.grpc.lookup.v1.RouteLookupServiceGrpc
-
Creates a new ListenableFuture-style stub that supports unary calls on the service
- newFutureStub(Channel) - Static method in class io.grpc.reflection.v1.ServerReflectionGrpc
-
Creates a new ListenableFuture-style stub that supports unary calls on the service
- newFutureStub(Channel) - Static method in class io.grpc.reflection.v1alpha.ServerReflectionGrpc
-
Creates a new ListenableFuture-style stub that supports unary calls on the service
- newHandler(ServerTransportListener, ChannelPromise, List<? extends ServerStreamTracer.Factory>, TransportTracer, int, boolean, int, int, int, long, long, long, long, long, boolean, long, int, long, Attributes) - Static method in class io.grpc.netty.NettyServerHandler
- newHandler(ClientTransportLifecycleManager, KeepAliveManager, boolean, int, int, Supplier<Stopwatch>, Runnable, TransportTracer, Attributes, String, ChannelLogger, Ticker) - Static method in class io.grpc.netty.NettyClientHandler
- newHandler(GrpcHttp2ConnectionHandler) - Method in class io.grpc.netty.InternalProtocolNegotiator.ProtocolNegotiatorAdapter
- newHandler(GrpcHttp2ConnectionHandler) - Method in interface io.grpc.netty.ProtocolNegotiator
-
Creates a new handler to control the protocol negotiation.
- newHandler(GrpcHttp2ConnectionHandler) - Method in class io.grpc.netty.ProtocolNegotiators.ClientTlsProtocolNegotiator
- newHandler(GrpcHttp2ConnectionHandler) - Method in class io.grpc.netty.ProtocolNegotiators.PlaintextProtocolNegotiator
- newHandler(GrpcHttp2ConnectionHandler) - Method in class io.grpc.netty.ProtocolNegotiators.PlaintextUpgradeProtocolNegotiator
- newHandler(ChannelPromise, Http2FrameReader, Http2FrameWriter, ServerTransportListener, List<? extends ServerStreamTracer.Factory>, TransportTracer, int, boolean, int, int, int, long, long, long, long, long, boolean, long, int, long, Attributes, Ticker) - Static method in class io.grpc.netty.NettyServerHandler
- newHandler(Http2Connection, Http2FrameReader, Http2FrameWriter, ClientTransportLifecycleManager, KeepAliveManager, boolean, int, int, Supplier<Stopwatch>, Runnable, TransportTracer, Attributes, String, ChannelLogger, Ticker) - Static method in class io.grpc.netty.NettyClientHandler
- newHeaders() - Method in class io.grpc.netty.GrpcHttp2HeadersUtils.GrpcHttp2ClientHeadersDecoder
- newHeaders() - Method in class io.grpc.netty.GrpcHttp2HeadersUtils.GrpcHttp2ServerHeadersDecoder
- newHealthCheckingLoadBalancer(LoadBalancer.Factory, LoadBalancer.Helper) - Static method in class io.grpc.protobuf.services.HealthCheckingLoadBalancerUtil
-
Creates a health-checking-capable LoadBalancer.
- newInstance() - Static method in class io.grpc.protobuf.services.ProtoReflectionService
- newInstance() - Static method in class io.grpc.protobuf.services.ProtoReflectionServiceV1
-
Creates a instance of
ProtoReflectionServiceV1
. - newInstance() - Static method in class io.grpc.services.MetricRecorder
- newInstance(int) - Static method in class io.grpc.protobuf.services.ChannelzService
-
Creates an instance.
- newInstance(int) - Static method in class io.grpc.services.ChannelzService
-
Deprecated.Creates an instance.
- newInterceptor(String) - Method in interface io.grpc.ManagedChannelBuilder.InterceptorFactory
- newLoadBalancer(LoadBalancer.Helper) - Method in class io.grpc.grpclb.GrpclbLoadBalancerProvider
- newLoadBalancer(LoadBalancer.Helper) - Method in class io.grpc.internal.AutoConfiguredLoadBalancerFactory
- newLoadBalancer(LoadBalancer.Helper) - Method in class io.grpc.internal.PickFirstLoadBalancerProvider
- newLoadBalancer(LoadBalancer.Helper) - Method in class io.grpc.LoadBalancer.Factory
-
Creates a
LoadBalancer
that will be used inside a channel. - newLoadBalancer(LoadBalancer.Helper) - Method in class io.grpc.protobuf.services.HealthCheckingLoadBalancerFactory
- newLoadBalancer(LoadBalancer.Helper) - Method in class io.grpc.protobuf.services.internal.HealthCheckingRoundRobinLoadBalancerProvider
- newLoadBalancer(LoadBalancer.Helper) - Method in class io.grpc.rls.RlsLoadBalancerProvider
- newLoadBalancer(LoadBalancer.Helper) - Method in class io.grpc.util.OutlierDetectionLoadBalancerProvider
- newLoadBalancer(LoadBalancer.Helper) - Method in class io.grpc.util.SecretRoundRobinLoadBalancerProvider.Provider
- newMetadata(byte[]...) - Static method in class io.grpc.InternalMetadata
- newMetadata(int, byte[]...) - Static method in class io.grpc.InternalMetadata
- newMetadataWithParsedValues(int, Object[]) - Static method in class io.grpc.InternalMetadata
-
Creates a new
Metadata
instance from serialized data, with some values pre-parsed. - newNameResolver(URI, NameResolver.Args) - Method in class io.grpc.grpclb.SecretGrpclbNameResolverProvider.Provider
- newNameResolver(URI, NameResolver.Args) - Method in class io.grpc.internal.DnsNameResolverProvider
- newNameResolver(URI, NameResolver.Args) - Method in class io.grpc.internal.ManagedChannelImplBuilder.DirectAddressNameResolverProvider
- newNameResolver(URI, NameResolver.Args) - Method in class io.grpc.internal.NameResolverFactoryToProviderFacade
- newNameResolver(URI, NameResolver.Args) - Method in class io.grpc.NameResolver.Factory
-
Creates a
NameResolver
for the given target URI, ornull
if the given URI cannot be resolved by this factory. - newNameResolver(URI, NameResolver.Args) - Method in class io.grpc.NameResolverRegistry.NameResolverFactory
- newNameResolver(URI, NameResolver.Args) - Method in class io.grpc.netty.UdsNameResolverProvider
- newNegotiator() - Method in interface io.grpc.netty.InternalProtocolNegotiator.ClientFactory
- newNegotiator() - Method in class io.grpc.netty.NettyChannelBuilder.DefaultProtocolNegotiator
- newNegotiator() - Method in interface io.grpc.netty.ProtocolNegotiator.ClientFactory
-
Creates a new negotiator.
- newNegotiator() - Method in class io.grpc.netty.ProtocolNegotiators.PlaintextProtocolNegotiatorClientFactory
- newNegotiator() - Method in class io.grpc.netty.ProtocolNegotiators.PlaintextUpgradeProtocolNegotiatorClientFactory
- newNegotiator() - Method in class io.grpc.netty.ProtocolNegotiators.TlsProtocolNegotiatorClientFactory
- newNegotiator(ObjectPool<? extends Executor>) - Method in interface io.grpc.netty.InternalProtocolNegotiator.ServerFactory
- newNegotiator(ObjectPool<? extends Executor>) - Method in interface io.grpc.netty.ProtocolNegotiator.ServerFactory
-
Creates a new negotiator.
- newNegotiator(ObjectPool<? extends Executor>) - Method in class io.grpc.netty.ProtocolNegotiators.FixedProtocolNegotiatorServerFactory
- newNegotiator(ObjectPool<? extends Executor>) - Method in class io.grpc.netty.ProtocolNegotiators.PlaintextProtocolNegotiatorServerFactory
- newNegotiator(ObjectPool<? extends Executor>) - Method in class io.grpc.netty.ProtocolNegotiators.TlsProtocolNegotiatorServerFactory
- newProvider() - Static method in class io.grpc.internal.ConscryptLoader
-
Same as
Conscrypt.newProvider()
. - newResourceResolver() - Method in interface io.grpc.internal.DnsNameResolver.ResourceResolverFactory
-
Creates a new resource resolver.
- newResourceResolver() - Method in class io.grpc.internal.JndiResourceResolverFactory
- newRoundRobinProvider() - Static method in class io.grpc.protobuf.services.internal.HealthCheckingRoundRobinLoadBalancerProvider
- newServerBuilderForPort(int, ServerCredentials) - Static method in class io.grpc.Grpc
-
Static factory for creating a new ServerBuilder.
- newServerBuilderForPort(int, ServerCredentials) - Method in class io.grpc.netty.NettyServerProvider
- newServerBuilderForPort(int, ServerCredentials) - Method in class io.grpc.ServerProvider
-
Creates a new builder with the given port and credentials.
- newServerBuilderForPort(int, ServerCredentials) - Method in class io.grpc.ServerRegistry
- newServerBuilderForPort(ServerProvider, int, ServerCredentials) - Static method in class io.grpc.InternalServerProvider
- NewServerBuilderResult(ServerBuilder<?>, String) - Constructor for class io.grpc.ServerProvider.NewServerBuilderResult
- newServerContext(List<? extends ServerStreamTracer.Factory>, String, Metadata) - Static method in class io.grpc.internal.StatsTraceContext
-
Factory method for the server-side.
- newServerStreamListener(ServerCall.Listener<ReqT>) - Method in class io.grpc.internal.ServerCallImpl
- newServerStreamTracer(String, Metadata) - Method in class io.grpc.ServerStreamTracer.Factory
-
Creates a
ServerStreamTracer
for a new server stream. - newStream(MethodDescriptor<?, ?>, CallOptions, Metadata, Context) - Method in interface io.grpc.internal.ClientCallImpl.ClientStreamProvider
- newStream(MethodDescriptor<?, ?>, CallOptions, Metadata, Context) - Method in class io.grpc.internal.ManagedChannelImpl.ChannelStreamProvider
- newStream(MethodDescriptor<?, ?>, Metadata, CallOptions, ClientStreamTracer[]) - Method in class io.grpc.inprocess.InProcessTransport
- newStream(MethodDescriptor<?, ?>, Metadata, CallOptions, ClientStreamTracer[]) - Method in class io.grpc.internal.CallCredentialsApplyingTransportFactory.CallCredentialsApplyingTransport
- newStream(MethodDescriptor<?, ?>, Metadata, CallOptions, ClientStreamTracer[]) - Method in interface io.grpc.internal.ClientTransport
-
Creates a new stream for sending messages to a remote end-point.
- newStream(MethodDescriptor<?, ?>, Metadata, CallOptions, ClientStreamTracer[]) - Method in class io.grpc.internal.DelayedClientTransport
-
If a
LoadBalancer.SubchannelPicker
is being, or has been provided viaDelayedClientTransport.reprocess(io.grpc.LoadBalancer.SubchannelPicker)
, the last picker will be consulted. - newStream(MethodDescriptor<?, ?>, Metadata, CallOptions, ClientStreamTracer[]) - Method in class io.grpc.internal.FailingClientTransport
- newStream(MethodDescriptor<?, ?>, Metadata, CallOptions, ClientStreamTracer[]) - Method in class io.grpc.internal.ForwardingConnectionClientTransport
- newStream(MethodDescriptor<?, ?>, Metadata, CallOptions, ClientStreamTracer[]) - Method in class io.grpc.internal.InternalSubchannel.CallTracingTransport
- newStream(MethodDescriptor<?, ?>, Metadata, CallOptions, ClientStreamTracer[]) - Method in class io.grpc.netty.NettyClientTransport
- newStreamException(int, Throwable) - Method in class io.grpc.netty.NettyServerHandler
- newStub(Channel) - Static method in class io.grpc.channelz.v1.ChannelzGrpc
-
Creates a new async stub that supports all call types for the service
- newStub(Channel) - Static method in class io.grpc.health.v1.HealthGrpc
-
Creates a new async stub that supports all call types for the service
- newStub(Channel) - Static method in class io.grpc.lb.v1.LoadBalancerGrpc
-
Creates a new async stub that supports all call types for the service
- newStub(Channel) - Static method in class io.grpc.lookup.v1.RouteLookupServiceGrpc
-
Creates a new async stub that supports all call types for the service
- newStub(Channel) - Static method in class io.grpc.reflection.v1.ServerReflectionGrpc
-
Creates a new async stub that supports all call types for the service
- newStub(Channel) - Static method in class io.grpc.reflection.v1alpha.ServerReflectionGrpc
-
Creates a new async stub that supports all call types for the service
- newStub(Channel, CallOptions) - Method in interface io.grpc.stub.AbstractStub.StubFactory
- newStub(AbstractStub.StubFactory<T>, Channel) - Static method in class io.grpc.stub.AbstractAsyncStub
-
Returns a new async stub with the given channel for the provided method configurations.
- newStub(AbstractStub.StubFactory<T>, Channel) - Static method in class io.grpc.stub.AbstractBlockingStub
-
Returns a new blocking stub with the given channel for the provided method configurations.
- newStub(AbstractStub.StubFactory<T>, Channel) - Static method in class io.grpc.stub.AbstractFutureStub
-
Returns a new future stub with the given channel for the provided method configurations.
- newStub(AbstractStub.StubFactory<T>, Channel) - Static method in class io.grpc.stub.AbstractStub
-
Returns a new stub with the given channel for the provided method configurations.
- newStub(AbstractStub.StubFactory<T>, Channel, CallOptions) - Static method in class io.grpc.stub.AbstractAsyncStub
-
Returns a new async stub with the given channel for the provided method configurations.
- newStub(AbstractStub.StubFactory<T>, Channel, CallOptions) - Static method in class io.grpc.stub.AbstractBlockingStub
-
Returns a new blocking stub with the given channel for the provided method configurations.
- newStub(AbstractStub.StubFactory<T>, Channel, CallOptions) - Static method in class io.grpc.stub.AbstractFutureStub
-
Returns a new future stub with the given channel for the provided method configurations.
- newStub(AbstractStub.StubFactory<T>, Channel, CallOptions) - Static method in class io.grpc.stub.AbstractStub
-
Returns a new stub with the given channel for the provided method configurations.
- newSubstream(Metadata, ClientStreamTracer.Factory, int, boolean) - Method in class io.grpc.internal.RetriableStream
-
Creates a new physical ClientStream that represents a retry/hedging attempt.
- newTimestampedBuilder() - Method in class io.grpc.protobuf.services.BinlogHelper.SinkWriterImpl
- next - Variable in class io.grpc.netty.ProtocolNegotiators.GrpcNegotiationHandler
- next - Variable in class io.grpc.netty.ProtocolNegotiators.Http2UpgradeAndGrpcHandler
- next - Variable in class io.grpc.netty.ProtocolNegotiators.ProtocolNegotiationHandler
- next - Variable in class io.grpc.netty.ProtocolNegotiators.ServerTlsHandler
- next - Variable in class io.grpc.netty.WriteBufferingAndExceptionHandler
- next() - Method in class io.grpc.inprocess.InProcessTransport.SingleMessageProducer
- next() - Method in class io.grpc.internal.ApplicationThreadDeframer.InitializingMessageProducer
- next() - Method in class io.grpc.internal.MessageDeframer.SingleMessageProducer
- next() - Method in class io.grpc.internal.MigratingThreadDeframer.DeframeMessageProducer
- next() - Method in interface io.grpc.internal.StreamListener.MessageProducer
-
Returns the next gRPC message, if the data has been received by the deframer and the application has requested another message.
- next() - Method in class io.grpc.netty.GrpcHttp2OutboundHeaders.Itr
-
This function is ordered specifically to get ideal performance on OpenJDK.
- next() - Method in class io.grpc.stub.ClientCalls.BlockingResponseStream
- NEXT_PROTOCOL_VERSIONS - Static variable in class io.grpc.netty.GrpcSslContexts
- nextAvailableMetricIndex - Variable in class io.grpc.MetricInstrumentRegistry
- nextBackoffIntervalNanos - Variable in class io.grpc.internal.RetriableStream
- nextBackoffNanos - Variable in class io.grpc.internal.ExponentialBackoffPolicy
- nextBackoffNanos() - Method in interface io.grpc.internal.BackoffPolicy
-
Returns the number of nanoseconds to wait.
- nextBackoffNanos() - Method in class io.grpc.internal.ExponentialBackoffPolicy
- nextFrame - Variable in class io.grpc.internal.MessageDeframer
- nextIdleMonitorTime - Variable in class io.grpc.internal.MaxConnectionIdleManager
- nextIndex() - Method in class io.grpc.util.RoundRobinLoadBalancer.ReadyPicker
- NIO - Enum constant in enum io.grpc.netty.Utils.EventLoopGroupType
- NIO_BOSS_EVENT_LOOP_GROUP - Static variable in class io.grpc.netty.Utils
- NIO_WORKER_EVENT_LOOP_GROUP - Static variable in class io.grpc.netty.Utils
- nioServerChannelFactory() - Static method in class io.grpc.netty.Utils
- NO_AVAILABLE_BACKENDS_STATUS - Static variable in class io.grpc.grpclb.GrpclbState
- NO_CONFIG - Static variable in class io.grpc.util.SecretRoundRobinLoadBalancerProvider.Provider
- NO_ERROR - Enum constant in enum io.grpc.internal.GrpcUtil.Http2Error
-
Servers implementing a graceful shutdown of the connection will send
GOAWAY
withNO_ERROR
. - NO_FALLBACK_BACKENDS_STATUS - Static variable in class io.grpc.grpclb.GrpclbState
- NO_LB_ADDRESS_PROVIDED_STATUS - Static variable in class io.grpc.grpclb.GrpclbState
- NO_MAX_OUTBOUND_MESSAGE_SIZE - Static variable in class io.grpc.internal.MessageFramer
- NO_RESOLUTION - Enum constant in enum io.grpc.internal.ManagedChannelImpl.ResolutionState
- NO_RESULT - Static variable in class io.grpc.LoadBalancer.PickResult
- NO_USE_AUTHORITY_SUFFIX - Static variable in class io.grpc.grpclb.GrpclbState
- noMoreTransparentRetry - Variable in class io.grpc.internal.RetriableStream
-
Either non-local transparent retry happened or reached server's application logic.
- NON_EXISTENT_ID - Static variable in class io.grpc.netty.NettyClientStream.TransportState
- NONE - Enum constant in enum io.grpc.SecurityLevel
-
No security guarantee.
- NONE - Enum constant in enum io.grpc.TlsServerCredentials.ClientAuth
-
Clients will not present any identity.
- NONE - Static variable in class io.grpc.Codec.Identity
-
Special sentinel codec indicating that no compression should be used.
- nonFatalStatusCodes - Variable in class io.grpc.internal.HedgingPolicy
- NOOP - Static variable in class io.grpc.internal.StatsTraceContext
- NOOP - Static variable in class io.grpc.services.CallMetricRecorder
- NOOP_CALL - Static variable in class io.grpc.ClientInterceptors
- NOOP_CALL - Static variable in class io.grpc.internal.DelayedClientCall
- NOOP_CALL - Static variable in class io.grpc.internal.ManagedChannelImpl
- NOOP_LISTENER - Static variable in class io.grpc.internal.ServerImpl
- NOOP_MESSAGE - Static variable in class io.grpc.netty.NettyClientHandler
-
A message that simply passes through the channel without any real processing.
- NOOP_PICK_DETAILS_CONSUMER - Static variable in class io.grpc.internal.ManagedChannelImpl
- NOOP_PROXY_DETECTOR - Static variable in class io.grpc.internal.GrpcUtil
-
A proxy detector that always claims no proxy is needed.
- NOOP_TRACER - Static variable in class io.grpc.grpclb.TokenAttachingTracerFactory
- NOOP_TRACER - Static variable in class io.grpc.internal.GrpcUtil
- NoopClientStream - Class in io.grpc.internal
-
An implementation of
ClientStream
that silently does nothing for the operations. - NoopClientStream() - Constructor for class io.grpc.internal.NoopClientStream
- NoopListener() - Constructor for class io.grpc.internal.ServerImpl.NoopListener
- NoopLoadBalancer() - Constructor for class io.grpc.internal.AutoConfiguredLoadBalancerFactory.NoopLoadBalancer
- NoopStreamObserver() - Constructor for class io.grpc.stub.ServerCalls.NoopStreamObserver
- normalHeaders - Variable in class io.grpc.netty.GrpcHttp2OutboundHeaders
- normalizedDuration(long, int) - Static method in class io.grpc.internal.JsonUtil
-
Copy of
Durations.normalizedDuration(long, int)
. - NOT_ENOUGH_INFO_MESSAGE - Static variable in class io.grpc.util.AdvancedTlsX509TrustManager
- NOT_FOUND - Enum constant in enum io.grpc.Status.Code
-
Some requested entity (e.g., file or directory) was not found.
- NOT_FOUND - Static variable in class io.grpc.Status
-
Some requested entity (e.g., file or directory) was not found.
- NOT_READY_ERROR - Static variable in class io.grpc.internal.SubchannelChannel
- NOT_SERVING - Enum constant in enum io.grpc.health.v1.HealthCheckResponse.ServingStatus
-
NOT_SERVING = 2;
- NOT_SERVING_VALUE - Static variable in enum io.grpc.health.v1.HealthCheckResponse.ServingStatus
-
NOT_SERVING = 2;
- notAPetiolePolicy - Variable in class io.grpc.internal.PickFirstLeafLoadBalancer
- notifyAndClearListeners() - Method in class io.grpc.Context.CancellableContext
-
Notify all listeners that this context has been cancelled and immediately release any reference to them so that they may be garbage collected.
- notifyClientClose(Status, Metadata) - Method in class io.grpc.inprocess.InProcessTransport.InProcessStream.InProcessServerStream
-
clientStream.serverClosed() must be called before this method
- notifyFailed(ClientTransport.PingCallback, Executor, Throwable) - Static method in class io.grpc.internal.Http2Ping
-
Notifies the given callback that the ping operation failed.
- notifyGracefulShutdown(Status) - Method in class io.grpc.netty.ClientTransportLifecycleManager
-
Marks transport as shutdown, but does not set the error status.
- notifyIfReady() - Method in class io.grpc.internal.AbstractStream.TransportState
- notifyInUse(boolean) - Method in class io.grpc.netty.ClientTransportLifecycleManager
- notifyReady() - Method in class io.grpc.netty.ClientTransportLifecycleManager
- notifyShutdown(Status) - Method in class io.grpc.inprocess.InProcessTransport
- notifyShutdown(Status) - Method in class io.grpc.netty.ClientTransportLifecycleManager
-
Returns
true
if was the first shutdown. - notifyTerminated() - Method in class io.grpc.inprocess.InProcessTransport
- notifyTerminated(Status) - Method in class io.grpc.netty.ClientTransportLifecycleManager
- notifyTerminated(Throwable) - Method in class io.grpc.netty.NettyServerTransport
- notifyUnused() - Method in class io.grpc.netty.GrpcHttp2ConnectionHandler
-
Calling this method indicates that the channel will no longer be used.
- notifyWatchers(String, HealthCheckResponse.ServingStatus) - Method in class io.grpc.protobuf.services.HealthServiceImpl
- notifyWhenStateChanged(ConnectivityState, Runnable) - Method in class io.grpc.internal.ForwardingManagedChannel
- notifyWhenStateChanged(ConnectivityState, Runnable) - Method in class io.grpc.internal.ManagedChannelImpl
- notifyWhenStateChanged(ConnectivityState, Runnable) - Method in class io.grpc.ManagedChannel
-
Registers a one-off callback that will be run if the connectivity state of the channel diverges from the given
source
, which is typically what has just been returned byManagedChannel.getState(boolean)
. - notifyWhenStateChanged(Runnable, Executor, ConnectivityState) - Method in class io.grpc.internal.ConnectivityStateManager
-
Adds a listener for state change event.
- notReadyTransport - Static variable in class io.grpc.internal.SubchannelChannel
- NPN - Static variable in class io.grpc.netty.GrpcSslContexts
- NPN_AND_ALPN - Static variable in class io.grpc.netty.GrpcSslContexts
- num - Variable in class io.grpc.grpclb.GrpclbClientLoadRecorder.LongHolder
- NUM_CALLS_FIELD_NUMBER - Static variable in class io.grpc.lb.v1.ClientStatsPerToken
- NUM_CALLS_FINISHED_FIELD_NUMBER - Static variable in class io.grpc.lb.v1.ClientStats
- NUM_CALLS_FINISHED_KNOWN_RECEIVED_FIELD_NUMBER - Static variable in class io.grpc.lb.v1.ClientStats
- NUM_CALLS_FINISHED_WITH_CLIENT_FAILED_TO_SEND_FIELD_NUMBER - Static variable in class io.grpc.lb.v1.ClientStats
- NUM_CALLS_STARTED_FIELD_NUMBER - Static variable in class io.grpc.lb.v1.ClientStats
- NUM_EVENTS_LOGGED_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.ChannelTrace
- NUM_SLOTS - Static variable in class io.grpc.rls.AdaptiveThrottler.TimeBasedAccumulator
-
The number of slots.
- numCalls_ - Variable in class io.grpc.lb.v1.ClientStatsPerToken.Builder
- numCalls_ - Variable in class io.grpc.lb.v1.ClientStatsPerToken
- numCallsFinished_ - Variable in class io.grpc.lb.v1.ClientStats.Builder
- numCallsFinished_ - Variable in class io.grpc.lb.v1.ClientStats
- numCallsFinishedKnownReceived_ - Variable in class io.grpc.lb.v1.ClientStats.Builder
- numCallsFinishedKnownReceived_ - Variable in class io.grpc.lb.v1.ClientStats
- numCallsFinishedWithClientFailedToSend_ - Variable in class io.grpc.lb.v1.ClientStats.Builder
- numCallsFinishedWithClientFailedToSend_ - Variable in class io.grpc.lb.v1.ClientStats
- numCallsStarted_ - Variable in class io.grpc.lb.v1.ClientStats.Builder
- numCallsStarted_ - Variable in class io.grpc.lb.v1.ClientStats
- numEventLoops - Variable in class io.grpc.netty.Utils.DefaultEventLoopGroupResource
- numEventsLogged - Variable in class io.grpc.InternalChannelz.ChannelTrace.Builder
- numEventsLogged - Variable in class io.grpc.InternalChannelz.ChannelTrace
- numEventsLogged_ - Variable in class io.grpc.channelz.v1.ChannelTrace.Builder
- numEventsLogged_ - Variable in class io.grpc.channelz.v1.ChannelTrace
- numHeaders() - Method in class io.grpc.netty.GrpcHttp2HeadersUtils.GrpcHttp2InboundHeaders
-
Returns the number of none-null headers in
GrpcHttp2HeadersUtils.GrpcHttp2InboundHeaders.namesAndValues()
. - numSentBytesQueued - Variable in class io.grpc.internal.AbstractStream.TransportState
-
The number of bytes currently queued, waiting to be sent.
- numTf - Variable in class io.grpc.internal.PickFirstLeafLoadBalancer
- numWatchersForTest(String) - Method in class io.grpc.protobuf.services.HealthServiceImpl
O
- OBJ_OVERHEAD_B - Static variable in class io.grpc.rls.CachingRlsLbClient
-
Minimum bytes for a Java Object.
- object - Variable in class io.grpc.internal.FixedObjectPool
- ObjectPool<T> - Interface in io.grpc.internal
-
An object pool.
- observer - Variable in class io.grpc.internal.ClientCallImpl.ClientStreamListenerImpl
- observer - Variable in class io.grpc.stub.ClientCalls.StreamObserverToCallListenerAdapter
- obtainActiveTransport() - Method in class io.grpc.internal.InternalSubchannel
- obtainActiveTransport() - Method in interface io.grpc.internal.TransportProvider
-
Returns a READY transport that will be used to create new streams.
- of(LbPolicyConfiguration.ChildPolicyWrapper) - Static method in class io.grpc.rls.LbPolicyConfiguration.RefCountedChildPolicyWrapper
- of(ClientCalls.StubType) - Static method in enum io.grpc.stub.InternalClientCalls.StubType
-
Returns companion enum value of passed internal enum equivalent.
- of(String) - Static method in class io.grpc.Attributes.Key
-
Deprecated.use
Attributes.Key.create(java.lang.String)
instead. This method will be removed in the future. - of(String, boolean, Metadata.AsciiMarshaller<T>) - Static method in class io.grpc.Metadata.Key
- of(String, boolean, Metadata.TrustedAsciiMarshaller<T>) - Static method in class io.grpc.Metadata.Key
- of(String, Metadata.AsciiMarshaller<T>) - Static method in class io.grpc.Metadata.Key
-
Creates a key for an ASCII header.
- of(String, Metadata.BinaryMarshaller<T>) - Static method in class io.grpc.Metadata.Key
-
Creates a key for a binary header.
- of(String, Metadata.BinaryStreamMarshaller<T>) - Static method in class io.grpc.Metadata.Key
-
Creates a key for a binary header, serializing to input streams.
- of(String, T) - Static method in class io.grpc.CallOptions.Key
-
Deprecated.Use
CallOptions.Key.create(java.lang.String)
orCallOptions.Key.createWithDefault(java.lang.String, T)
instead. This method will be removed. - offloadExecutor(Executor) - Method in class io.grpc.ForwardingChannelBuilder
- offloadExecutor(Executor) - Method in class io.grpc.ForwardingChannelBuilder2
- offloadExecutor(Executor) - Method in class io.grpc.internal.ManagedChannelImplBuilder
- offloadExecutor(Executor) - Method in class io.grpc.ManagedChannelBuilder
-
Provides a custom executor that will be used for operations that block or are expensive, to avoid blocking asynchronous code paths.
- offloadExecutorHolder - Variable in class io.grpc.internal.ManagedChannelImpl
- offloadExecutorPool - Variable in class io.grpc.internal.ManagedChannelImplBuilder
- offset - Variable in class io.grpc.internal.ReadableBuffers.ByteArrayWrapper
- offset(long, TimeUnit) - Method in class io.grpc.Deadline
-
Create a new deadline that is offset from
this
. - OK - Enum constant in enum io.grpc.Status.Code
-
The operation completed successfully.
- 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.
- onAddresses(List<EquivalentAddressGroup>, Attributes) - Method in class io.grpc.NameResolver.Listener2
-
Deprecated.This will be removed in 1.22.0
- onAllDataRead() - Method in class io.grpc.servlet.jakarta.ServletAdapter.GrpcReadListener
- onAllDataRead() - Method in class io.grpc.servlet.ServletAdapter.GrpcReadListener
- onCancel() - Method in class io.grpc.Contexts.ContextualizedServerCallListener
- onCancel() - Method in class io.grpc.PartialForwardingServerCallListener
- 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.
- onCancel() - Method in class io.grpc.stub.ServerCalls.StreamingServerCallHandler.StreamingServerCallListener
- onCancel() - Method in class io.grpc.stub.ServerCalls.UnaryServerCallHandler.UnaryServerCallListener
- onCancelHandler - Variable in class io.grpc.stub.ServerCalls.ServerCallStreamObserverImpl
- onClose(Status, Metadata) - Method in class io.grpc.ClientCall.Listener
-
The ClientCall has been closed.
- onClose(Status, Metadata) - Method in class io.grpc.internal.DelayedClientCall.DelayedListener
- onClose(Status, Metadata) - Method in class io.grpc.PartialForwardingClientCallListener
- onClose(Status, Metadata) - Method in class io.grpc.protobuf.services.HealthCheckingLoadBalancerFactory.HealthCheckState.HcStream
- onClose(Status, Metadata) - Method in class io.grpc.stub.ClientCalls.BlockingResponseStream.QueuingListener
- onClose(Status, Metadata) - Method in class io.grpc.stub.ClientCalls.StreamObserverToCallListenerAdapter
- onClose(Status, Metadata) - Method in class io.grpc.stub.ClientCalls.UnaryStreamToFuture
- onClose(Status, Metadata) - Method in class io.grpc.stub.MetadataUtils.MetadataCapturingClientInterceptor.MetadataCapturingClientCall.MetadataCapturingClientCallListener
- onCloseHandler - Variable in class io.grpc.stub.ServerCalls.ServerCallStreamObserverImpl
- onComplete() - Method in class io.grpc.Contexts.ContextualizedServerCallListener
- onComplete() - Method in interface io.grpc.internal.MetadataApplierImpl.MetadataApplierListener
-
Notify that the metadata has been successfully applied, or failed.
- onComplete() - Method in class io.grpc.PartialForwardingServerCallListener
- onComplete() - Method in class io.grpc.ServerCall.Listener
-
The call is considered complete and
ServerCall.Listener.onCancel()
is guaranteed not to be called. - onComplete() - Method in class io.grpc.stub.ServerCalls.StreamingServerCallHandler.StreamingServerCallListener
- onComplete() - Method in class io.grpc.stub.ServerCalls.UnaryServerCallHandler.UnaryServerCallListener
- onComplete(AsyncEvent) - Method in class io.grpc.servlet.jakarta.ServletAdapter.GrpcAsyncListener
- onComplete(AsyncEvent) - Method in class io.grpc.servlet.ServletAdapter.GrpcAsyncListener
- onCompleted() - Method in class io.grpc.grpclb.GrpclbState.LbStream
- onCompleted() - Method in class io.grpc.protobuf.services.ProtoReflectionServiceV1.ProtoReflectionStreamObserver
- onCompleted() - Method in class io.grpc.stub.ClientCalls.CallToStreamObserverAdapter
- onCompleted() - Method in class io.grpc.stub.ServerCalls.NoopStreamObserver
- onCompleted() - Method in class io.grpc.stub.ServerCalls.ServerCallStreamObserverImpl
- onCompleted() - Method in interface io.grpc.stub.StreamObserver
-
Receives a notification of successful stream completion.
- onConfigError() - Method in class io.grpc.internal.ManagedChannelImpl.RealChannel
- onConnectionError(ChannelHandlerContext, boolean, Throwable, Http2Exception) - Method in class io.grpc.netty.NettyClientHandler
- onConnectionError(ChannelHandlerContext, boolean, Throwable, Http2Exception) - Method in class io.grpc.netty.NettyServerHandler
- onDataAvailable() - Method in class io.grpc.servlet.jakarta.ServletAdapter.GrpcReadListener
- onDataAvailable() - Method in class io.grpc.servlet.ServletAdapter.GrpcReadListener
- onDataRead(int, int) - Method in class io.grpc.netty.AbstractNettyHandler.FlowControlPinger
- onDataRead(int, ByteBuf, int, boolean) - Method in class io.grpc.netty.NettyClientHandler
-
Handler for an inbound HTTP/2 DATA frame.
- onDataRead(int, ByteBuf, int, boolean) - Method in class io.grpc.netty.NettyServerHandler
- onDataRead(ChannelHandlerContext, int, ByteBuf, int, boolean) - Method in class io.grpc.netty.NettyClientHandler.FrameListener
- onDataRead(ChannelHandlerContext, int, ByteBuf, int, boolean) - Method in class io.grpc.netty.NettyServerHandler.FrameListener
- onDataReceived() - Method in class io.grpc.internal.KeepAliveManager
-
Transport has received some data so that we can delay sending keepalives.
- one - Static variable in class io.grpc.internal.ReflectionLongAdderCounter
- onEarlyCancellation(Status) - Method in class io.grpc.internal.DelayedClientTransport.PendingStream
- onEarlyCancellation(Status) - Method in class io.grpc.internal.DelayedStream
- onError(Status) - Method in class io.grpc.internal.ManagedChannelImpl.NameResolverListener
- onError(Status) - Method in class io.grpc.internal.RetryingNameResolver.RetryingListener
- onError(Status) - Method in interface io.grpc.NameResolver.Listener
-
Handles an error from the resolver.
- onError(Status) - Method in class io.grpc.NameResolver.Listener2
-
Handles a name resolving error from the resolver.
- onError(AsyncEvent) - Method in class io.grpc.servlet.jakarta.ServletAdapter.GrpcAsyncListener
- onError(Throwable) - Method in class io.grpc.grpclb.GrpclbState.LbStream
- onError(Throwable) - Method in class io.grpc.protobuf.services.ProtoReflectionServiceV1.ProtoReflectionStreamObserver
- onError(Throwable) - Method in class io.grpc.servlet.jakarta.ServletAdapter.GrpcReadListener
- onError(Throwable) - Method in class io.grpc.servlet.jakarta.ServletServerStream.GrpcWriteListener
- onError(Throwable) - Method in class io.grpc.servlet.ServletAdapter.GrpcReadListener
- onError(Throwable) - Method in class io.grpc.servlet.ServletServerStream.GrpcWriteListener
- onError(Throwable) - Method in class io.grpc.stub.ClientCalls.CallToStreamObserverAdapter
- onError(Throwable) - Method in class io.grpc.stub.ServerCalls.NoopStreamObserver
- onError(Throwable) - Method in class io.grpc.stub.ServerCalls.ServerCallStreamObserverImpl
- onError(Throwable) - Method in interface io.grpc.stub.StreamObserver
-
Receives a terminating error from the stream.
- onError(AsyncEvent) - Method in class io.grpc.servlet.ServletAdapter.GrpcAsyncListener
- onEviction(RlsProtoData.RouteLookupRequest, CachingRlsLbClient.CacheEntry, LruCache.EvictionType) - Method in class io.grpc.rls.CachingRlsLbClient.AutoCleaningEvictionListener
- onEviction(K, LinkedHashLruCache.SizedValue, LruCache.EvictionType) - Method in class io.grpc.rls.LinkedHashLruCache.SizeHandlingEvictionListener
- onEviction(K, V, LruCache.EvictionType) - Method in interface io.grpc.rls.LruCache.EvictionListener
-
Notifies the listener when any cache entry is evicted.
- onFailure(Throwable) - Method in interface io.grpc.internal.ClientTransport.PingCallback
-
Invoked when a ping fails.
- onHalfClose() - Method in class io.grpc.Contexts.ContextualizedServerCallListener
- onHalfClose() - Method in class io.grpc.PartialForwardingServerCallListener
- onHalfClose() - Method in class io.grpc.ServerCall.Listener
-
The client completed all message sending.
- onHalfClose() - Method in class io.grpc.stub.ServerCalls.StreamingServerCallHandler.StreamingServerCallListener
- onHalfClose() - Method in class io.grpc.stub.ServerCalls.UnaryServerCallHandler.UnaryServerCallListener
- onHeaders(Metadata) - Method in class io.grpc.ClientCall.Listener
-
The response headers have been received.
- onHeaders(Metadata) - Method in class io.grpc.internal.DelayedClientCall.DelayedListener
- onHeaders(Metadata) - Method in class io.grpc.PartialForwardingClientCallListener
- onHeaders(Metadata) - Method in class io.grpc.stub.ClientCalls.BlockingResponseStream.QueuingListener
- onHeaders(Metadata) - Method in class io.grpc.stub.ClientCalls.StreamObserverToCallListenerAdapter
- onHeaders(Metadata) - Method in class io.grpc.stub.ClientCalls.UnaryStreamToFuture
- onHeaders(Metadata) - Method in class io.grpc.stub.MetadataUtils.MetadataCapturingClientInterceptor.MetadataCapturingClientCall.MetadataCapturingClientCallListener
- onHeadersRead(int, Http2Headers, boolean) - Method in class io.grpc.netty.NettyClientHandler
- onHeadersRead(ChannelHandlerContext, int, Http2Headers) - Method in class io.grpc.netty.NettyServerHandler
- onHeadersRead(ChannelHandlerContext, int, Http2Headers, int, short, boolean, int, boolean) - Method in class io.grpc.netty.NettyClientHandler.FrameListener
- onHeadersRead(ChannelHandlerContext, int, Http2Headers, int, short, boolean, int, boolean) - Method in class io.grpc.netty.NettyServerHandler.FrameListener
- onInUse(InternalSubchannel) - Method in class io.grpc.internal.InternalSubchannel.Callback
-
Called when the subchannel's in-use state has changed to true, which means at least one transport is in use.
- onMessage(HealthCheckResponse) - Method in class io.grpc.protobuf.services.HealthCheckingLoadBalancerFactory.HealthCheckState.HcStream
- onMessage(ReqT) - Method in class io.grpc.Contexts.ContextualizedServerCallListener
- onMessage(ReqT) - Method in class io.grpc.ForwardingServerCallListener
- onMessage(ReqT) - Method in class io.grpc.ServerCall.Listener
-
A request message has been received.
- onMessage(ReqT) - Method in class io.grpc.stub.ServerCalls.StreamingServerCallHandler.StreamingServerCallListener
- onMessage(ReqT) - Method in class io.grpc.stub.ServerCalls.UnaryServerCallHandler.UnaryServerCallListener
- onMessage(RespT) - Method in class io.grpc.ForwardingClientCallListener
- onMessage(RespT) - Method in class io.grpc.internal.DelayedClientCall.DelayedListener
- onMessage(RespT) - Method in class io.grpc.stub.ClientCalls.StreamObserverToCallListenerAdapter
- onMessage(RespT) - Method in class io.grpc.stub.ClientCalls.UnaryStreamToFuture
- onMessage(T) - Method in class io.grpc.ClientCall.Listener
-
A response message has been received.
- onMessage(T) - Method in class io.grpc.stub.ClientCalls.BlockingResponseStream.QueuingListener
- onNext(LoadBalanceResponse) - Method in class io.grpc.grpclb.GrpclbState.LbStream
- onNext(ServerReflectionRequest) - Method in class io.grpc.protobuf.services.ProtoReflectionServiceV1.ProtoReflectionStreamObserver
- onNext(ReqT) - Method in class io.grpc.stub.ClientCalls.CallToStreamObserverAdapter
- onNext(RespT) - Method in class io.grpc.stub.ServerCalls.ServerCallStreamObserverImpl
- onNext(V) - Method in class io.grpc.stub.ServerCalls.NoopStreamObserver
- onNext(V) - Method in interface io.grpc.stub.StreamObserver
-
Receives a value from the stream.
- onNotInUse(InternalSubchannel) - Method in class io.grpc.internal.InternalSubchannel.Callback
-
Called when the subchannel's in-use state has changed to false, which means no transport is in use.
- onPingAckRead(ChannelHandlerContext, long) - Method in class io.grpc.netty.NettyClientHandler.FrameListener
- onPingAckRead(ChannelHandlerContext, long) - Method in class io.grpc.netty.NettyServerHandler.FrameListener
- onPingRead(ChannelHandlerContext, long) - Method in class io.grpc.netty.NettyClientHandler.FrameListener
- onPingRead(ChannelHandlerContext, long) - Method in class io.grpc.netty.NettyServerHandler.FrameListener
- 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.
- onPingTimeout() - Method in class io.grpc.netty.NettyServerHandler.KeepAlivePinger
- onQualifiedFailureThenCheckIsAboveThreshold() - Method in class io.grpc.internal.RetriableStream.Throttle
-
Counts down the token on qualified failure and checks if it is above the threshold atomically.
- onReady() - Method in class io.grpc.ClientCall.Listener
-
This indicates that the ClientCall may now be capable of sending additional messages (via
ClientCall.sendMessage(ReqT)
) without requiring excessive buffering internally. - onReady() - Method in class io.grpc.Contexts.ContextualizedServerCallListener
- onReady() - Method in class io.grpc.internal.ClientCallImpl.ClientStreamListenerImpl
- onReady() - Method in class io.grpc.internal.DelayedClientCall.DelayedListener
- onReady() - Method in class io.grpc.internal.DelayedStream.DelayedStreamListener
- onReady() - Method in class io.grpc.internal.ForwardingClientStreamListener
- onReady() - Method in class io.grpc.internal.RetriableStream.Sublistener
- onReady() - Method in class io.grpc.internal.ServerCallImpl.ServerStreamListenerImpl
- onReady() - Method in class io.grpc.internal.ServerImpl.JumpToApplicationThreadServerStreamListener
- onReady() - Method in class io.grpc.internal.ServerImpl.NoopListener
- 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.PartialForwardingClientCallListener
- onReady() - Method in class io.grpc.PartialForwardingServerCallListener
- onReady() - Method in class io.grpc.ServerCall.Listener
-
This indicates that the call may now be capable of sending additional messages (via
ServerCall.sendMessage(RespT)
) without requiring excessive buffering internally. - onReady() - Method in class io.grpc.stub.ClientCalls.StreamObserverToCallListenerAdapter
- onReady() - Method in class io.grpc.stub.ServerCalls.StreamingServerCallHandler.StreamingServerCallListener
- onReady() - Method in class io.grpc.stub.ServerCalls.UnaryServerCallHandler.UnaryServerCallListener
- onReadyHandler - Variable in class io.grpc.stub.ClientCalls.CallToStreamObserverAdapter
- onReadyHandler - Variable in class io.grpc.stub.ServerCalls.ServerCallStreamObserverImpl
- onReadyLock - Variable in class io.grpc.internal.AbstractStream.TransportState
- onReadyThreshold - Variable in class io.grpc.CallOptions.Builder
- onReadyThreshold - Variable in class io.grpc.CallOptions
- onReadyThreshold - Variable in class io.grpc.internal.AbstractStream.TransportState
- onResult(NameResolver.ResolutionResult) - Method in class io.grpc.internal.ManagedChannelImpl.NameResolverListener
- onResult(NameResolver.ResolutionResult) - Method in class io.grpc.internal.RetryingNameResolver.RetryingListener
- onResult(NameResolver.ResolutionResult) - Method in class io.grpc.NameResolver.Listener2
-
Handles updates on resolved addresses and attributes.
- onResult2(NameResolver.ResolutionResult) - Method in class io.grpc.internal.ManagedChannelImpl.NameResolverListener
- onResult2(NameResolver.ResolutionResult) - Method in class io.grpc.internal.RetryingNameResolver.RetryingListener
- onResult2(NameResolver.ResolutionResult) - Method in class io.grpc.NameResolver.Listener2
-
Handles updates on resolved addresses and attributes.
- onRstStreamRead(int, long) - Method in class io.grpc.netty.NettyClientHandler
-
Handler for an inbound HTTP/2 RST_STREAM frame, terminating a stream.
- onRstStreamRead(int, long) - Method in class io.grpc.netty.NettyServerHandler
- onRstStreamRead(ChannelHandlerContext, int, long) - Method in class io.grpc.netty.NettyClientHandler.FrameListener
- onRstStreamRead(ChannelHandlerContext, int, long) - Method in class io.grpc.netty.NettyServerHandler.FrameListener
- 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.
- onSendingBytes(int) - Method in class io.grpc.internal.AbstractStream.TransportState
-
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.
- onSettingsRead(ChannelHandlerContext, Http2Settings) - Method in class io.grpc.netty.NettyClientHandler.FrameListener
- onSettingsRead(ChannelHandlerContext, Http2Settings) - Method in class io.grpc.netty.NettyServerHandler.FrameListener
- onShutdown(Status) - Method in class io.grpc.internal.ManagedChannelImpl.UncommittedRetriableStreamsRegistry
- onShutdownNow(Status) - Method in class io.grpc.internal.ManagedChannelImpl.UncommittedRetriableStreamsRegistry
- onStart() - Method in class io.grpc.stub.ClientCalls.BlockingResponseStream.QueuingListener
- onStart() - Method in class io.grpc.stub.ClientCalls.StartableListener
- onStart() - Method in class io.grpc.stub.ClientCalls.StreamObserverToCallListenerAdapter
- onStart() - Method in class io.grpc.stub.ClientCalls.UnaryStreamToFuture
- onStartAsync(AsyncEvent) - Method in class io.grpc.servlet.jakarta.ServletAdapter.GrpcAsyncListener
- onStartAsync(AsyncEvent) - Method in class io.grpc.servlet.ServletAdapter.GrpcAsyncListener
- onStateChange(InternalSubchannel, ConnectivityStateInfo) - Method in class io.grpc.internal.InternalSubchannel.Callback
-
Called when the subchannel's connectivity state has changed.
- onStatusChanged(ConnectivityState) - Method in class io.grpc.rls.CachingRlsLbClient.BackoffRefreshListener
- onStatusChanged(ConnectivityState) - Method in interface io.grpc.rls.LbPolicyConfiguration.ChildLbStatusListener
-
Notifies when child lb status changes.
- 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.
- onStreamError(ChannelHandlerContext, boolean, Throwable, Http2Exception.StreamException) - Method in class io.grpc.netty.NettyClientHandler
- onStreamError(ChannelHandlerContext, boolean, Throwable, Http2Exception.StreamException) - Method in class io.grpc.netty.NettyServerHandler
- onSubchannelState(ConnectivityStateInfo) - Method in class io.grpc.internal.PickFirstLeafLoadBalancer.HealthListener
- onSubchannelState(ConnectivityStateInfo) - Method in interface io.grpc.LoadBalancer.SubchannelStateListener
-
Handles a state change on a Subchannel.
- onSubchannelState(ConnectivityStateInfo) - Method in class io.grpc.protobuf.services.HealthCheckingLoadBalancerFactory.HealthCheckState
- onSubchannelState(ConnectivityStateInfo) - Method in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionSubchannel.OutlierDetectionSubchannelStateListener
- onSubchannelState(LoadBalancer.Subchannel, ConnectivityStateInfo) - Method in interface io.grpc.grpclb.SubchannelPool.PooledSubchannelStateListener
-
Handles a state change on a Subchannel.
- onSuccess() - Method in class io.grpc.internal.RetriableStream.Throttle
- onSuccess(long) - Method in interface io.grpc.internal.ClientTransport.PingCallback
-
Invoked when a ping is acknowledged.
- onTerminated(InternalSubchannel) - Method in class io.grpc.internal.InternalSubchannel.Callback
-
Called when the subchannel is terminated, which means it's shut down and all transports have been terminated.
- onTimeout(AsyncEvent) - Method in class io.grpc.servlet.jakarta.ServletAdapter.GrpcAsyncListener
- onTimeout(AsyncEvent) - Method in class io.grpc.servlet.ServletAdapter.GrpcAsyncListener
- onTransportActive() - Method in class io.grpc.internal.KeepAliveEnforcer
-
There are outstanding RPCs on the transport.
- onTransportActive() - Method in class io.grpc.internal.KeepAliveManager
-
Transport has active streams.
- onTransportActive() - Method in class io.grpc.internal.MaxConnectionIdleManager
-
There are outstanding RPCs on the transport.
- onTransportIdle() - Method in class io.grpc.internal.KeepAliveEnforcer
-
There are no outstanding RPCs on the transport.
- onTransportIdle() - Method in class io.grpc.internal.KeepAliveManager
-
Transport has finished all streams.
- onTransportIdle() - Method in class io.grpc.internal.MaxConnectionIdleManager
-
There are no outstanding RPCs on the transport.
- onTransportStarted() - Method in class io.grpc.internal.KeepAliveManager
-
Start keepalive monitoring.
- onTransportTermination() - Method in class io.grpc.internal.KeepAliveManager
-
Transport is being terminated.
- onTransportTermination() - Method in class io.grpc.internal.MaxConnectionIdleManager
-
Transport is being terminated.
- onWriteFrameData(ChannelFuture, int, int) - Method in class io.grpc.netty.NettyClientStream.TransportState
- onWriteFrameData(ChannelFuture, int, int) - Method in class io.grpc.netty.NettyServerStream.TransportState
- onWritePossible() - Method in class io.grpc.servlet.AsyncServletOutputStreamWriter
-
Called from the container thread
WriteListener.onWritePossible()
. - onWritePossible() - Method in class io.grpc.servlet.jakarta.AsyncServletOutputStreamWriter
-
Called from the container thread
WriteListener.onWritePossible()
. - onWritePossible() - Method in class io.grpc.servlet.jakarta.ServletServerStream.GrpcWriteListener
- onWritePossible() - Method in class io.grpc.servlet.ServletServerStream.GrpcWriteListener
- OobChannel - Class in io.grpc.internal
-
A ManagedChannel backed by a single
InternalSubchannel
and used forLoadBalancer
to its own RPC needs. - OobChannel(String, ObjectPool<? extends Executor>, ScheduledExecutorService, SynchronizationContext, CallTracer, ChannelTracer, InternalChannelz, TimeProvider) - Constructor for class io.grpc.internal.OobChannel
- oobChannels - Variable in class io.grpc.internal.ManagedChannelImpl
- oobTransportFactory - Variable in class io.grpc.internal.ManagedChannelImpl
- OPENJSSE_PROVIDER_NAME - Static variable in class io.grpc.netty.GrpcSslContexts
- openStream(ReadableBuffer, boolean) - Static method in class io.grpc.internal.ReadableBuffers
-
Creates a new
InputStream
backed by the given buffer. - opQueue - Variable in class io.grpc.internal.MigratingThreadDeframer
- optimizeForDirectExecutor() - Method in class io.grpc.inprocess.InProcessTransport.InProcessStream.InProcessClientStream
- optimizeForDirectExecutor() - Method in class io.grpc.inprocess.InProcessTransport.InProcessStream.InProcessServerStream
- optimizeForDirectExecutor() - Method in class io.grpc.internal.AbstractStream
- optimizeForDirectExecutor() - Method in class io.grpc.internal.AbstractStream.TransportState
- optimizeForDirectExecutor() - Method in class io.grpc.internal.DelayedStream
- optimizeForDirectExecutor() - Method in class io.grpc.internal.ForwardingClientStream
- optimizeForDirectExecutor() - Method in class io.grpc.internal.NoopClientStream
- optimizeForDirectExecutor() - Method in class io.grpc.internal.RetriableStream
- optimizeForDirectExecutor() - Method in interface io.grpc.internal.Stream
-
Provides a hint that directExecutor is being used by the listener for callbacks to the application.
- option_ - Variable in class io.grpc.channelz.v1.SocketData.Builder
- option_ - Variable in class io.grpc.channelz.v1.SocketData
- OPTION_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.SocketData
- OPTIONAL - Enum constant in enum io.grpc.TlsServerCredentials.ClientAuth
-
Clients are requested to present their identity, but clients without identities are permitted.
- optionalInt(String) - Static method in class io.grpc.protobuf.services.BinlogHelper.FactoryImpl
-
Parses the optional int of the form "" (max int) or ":123" (123).
- optionalLabelKeys - Variable in class io.grpc.PartialMetricInstrument
- optionBuilder_ - Variable in class io.grpc.channelz.v1.SocketData.Builder
- options - Variable in class io.grpc.InternalChannelz.TcpInfo.Builder
- options - Variable in class io.grpc.InternalChannelz.TcpInfo
- orDefault(T, T) - Static method in class io.grpc.rls.RlsProtoConverters.RouteLookupConfigConverter
- origHeaders - Variable in class io.grpc.internal.MetadataApplierImpl
- ORIGINAL_REQUEST_FIELD_NUMBER - Static variable in class io.grpc.reflection.v1.ServerReflectionResponse
- ORIGINAL_REQUEST_FIELD_NUMBER - Static variable in class io.grpc.reflection.v1alpha.ServerReflectionResponse
- originalChannelCreds - Variable in class io.grpc.internal.ManagedChannelImpl
- originalName - Variable in class io.grpc.Metadata.Key
- originalName() - Method in class io.grpc.Metadata.Key
-
Returns the original name used to create this key.
- originalRequest_ - Variable in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
- originalRequest_ - Variable in class io.grpc.reflection.v1.ServerReflectionResponse
- originalRequest_ - Variable in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
- originalRequest_ - Variable in class io.grpc.reflection.v1alpha.ServerReflectionResponse
- originalRequestBuilder_ - Variable in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
- originalRequestBuilder_ - Variable in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
- originalTransportFactory - Variable in class io.grpc.internal.ManagedChannelImpl
- other - Variable in class io.grpc.InternalChannelz.Security
- OTHER - Enum constant in enum io.grpc.channelz.v1.Security.ModelCase
- OTHER_ADDRESS - Enum constant in enum io.grpc.channelz.v1.Address.AddressCase
- OTHER_ADDRESS_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.Address
- OTHER_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.Security
- OTHER_NAME - Enum constant in enum io.grpc.channelz.v1.Security.Tls.CipherSuiteCase
- OTHER_NAME_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.Security.Tls
- OtherAddress() - Constructor for class io.grpc.channelz.v1.Address.OtherAddress
- OtherAddress(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.channelz.v1.Address.OtherAddress
- otherAddressBuilder_ - Variable in class io.grpc.channelz.v1.Address.Builder
- otherBuilder_ - Variable in class io.grpc.channelz.v1.Security.Builder
- otherInfo - Variable in class io.grpc.netty.NettySocketSupport.NativeSocketOptions
- others - Variable in class io.grpc.InternalChannelz.SocketOptions.Builder
- others - Variable in class io.grpc.InternalChannelz.SocketOptions
- OtherSecurity() - Constructor for class io.grpc.channelz.v1.Security.OtherSecurity
- OtherSecurity(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.channelz.v1.Security.OtherSecurity
- OtherSecurity(String, Object) - Constructor for class io.grpc.InternalChannelz.OtherSecurity
-
Creates an instance.
- otherSockets - Variable in class io.grpc.InternalChannelz
- out - Variable in class io.grpc.protobuf.services.TempFileSink
- OUT_OF_RANGE - Enum constant in enum io.grpc.Status.Code
-
Operation was attempted past the valid range.
- OUT_OF_RANGE - Static variable in class io.grpc.Status
-
Operation was attempted past the valid range.
- outboundClosed - Variable in class io.grpc.internal.AbstractClientStream.TransportState
-
Whether the client has half-closed the stream.
- outboundClosed - Variable in class io.grpc.internal.AbstractServerStream
- outboundHeaders() - Method in class io.grpc.ClientStreamTracer
-
Headers has been sent to the socket.
- outboundHeaders() - Method in class io.grpc.grpclb.GrpclbClientLoadRecorder.StreamTracer
- outboundHeaders() - Method in class io.grpc.internal.ForwardingClientStreamTracer
- outboundHeaders() - Method in class io.grpc.util.ForwardingClientStreamTracer
- outboundMessage(int) - Method in class io.grpc.internal.ForwardingClientStreamTracer
- 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.
- outboundMessage(int) - Method in class io.grpc.util.ForwardingClientStreamTracer
- outboundMessageSent(int, long, long) - Method in class io.grpc.internal.ForwardingClientStreamTracer
- 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.
- outboundMessageSent(int, long, long) - Method in class io.grpc.util.ForwardingClientStreamTracer
- outboundSeqNo - Variable in class io.grpc.inprocess.InProcessTransport.InProcessStream.InProcessClientStream
- outboundSeqNo - Variable in class io.grpc.inprocess.InProcessTransport.InProcessStream.InProcessServerStream
- outboundUncompressedSize(long) - Method in class io.grpc.internal.ForwardingClientStreamTracer
- 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.
- outboundUncompressedSize(long) - Method in class io.grpc.util.ForwardingClientStreamTracer
- outboundWireSize(long) - Method in class io.grpc.internal.ForwardingClientStreamTracer
- outboundWireSize(long) - Method in class io.grpc.internal.RetriableStream.BufferSizeTracer
-
A message is sent to the wire, so its reference would be released if no retry or hedging were involved.
- 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.
- outboundWireSize(long) - Method in class io.grpc.util.ForwardingClientStreamTracer
- outlierDetectionEnabled() - Method in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig
-
Determine if any outlier detection algorithms are enabled in the config.
- OutlierDetectionLoadBalancer - Class in io.grpc.util
-
Wraps a child
LoadBalancer
while monitoring for outlier backends and removing them from the use of the child LB. - OutlierDetectionLoadBalancer(LoadBalancer.Helper, TimeProvider) - Constructor for class io.grpc.util.OutlierDetectionLoadBalancer
-
Creates a new instance of
OutlierDetectionLoadBalancer
. - OutlierDetectionLoadBalancer.ChildHelper - Class in io.grpc.util
-
This child helper wraps the provided helper so that it can hand out wrapped
OutlierDetectionLoadBalancer.OutlierDetectionSubchannel
s and manage the address info map. - OutlierDetectionLoadBalancer.DetectionTimer - Class in io.grpc.util
-
This timer will be invoked periodically, according to configuration, and it will look for any outlier subchannels.
- OutlierDetectionLoadBalancer.EndpointTracker - Class in io.grpc.util
-
Tracks additional information about the endpoint needed for outlier detection.
- OutlierDetectionLoadBalancer.EndpointTracker.CallCounter - Class in io.grpc.util
-
Tracks both successful and failed call counts.
- OutlierDetectionLoadBalancer.EndpointTrackerMap - Class in io.grpc.util
-
Maintains a mapping from endpoint (a set of addresses) to their trackers.
- OutlierDetectionLoadBalancer.FailurePercentageOutlierEjectionAlgorithm - Class in io.grpc.util
- OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig - Class in io.grpc.util
-
The configuration for
OutlierDetectionLoadBalancer
. - OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig.Builder - Class in io.grpc.util
- OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig.FailurePercentageEjection - Class in io.grpc.util
-
The configuration for failure percentage ejection.
- OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig.FailurePercentageEjection.Builder - Class in io.grpc.util
-
For building new
OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig.FailurePercentageEjection
instances. - OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig.SuccessRateEjection - Class in io.grpc.util
-
The configuration for success rate ejection.
- OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig.SuccessRateEjection.Builder - Class in io.grpc.util
-
Builds new instances of
OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig.SuccessRateEjection
. - OutlierDetectionLoadBalancer.OutlierDetectionPicker - Class in io.grpc.util
-
This picker delegates the actual picking logic to a wrapped delegate, but associates a
ClientStreamTracer
with each pick to track the results of each subchannel stream. - OutlierDetectionLoadBalancer.OutlierDetectionPicker.ResultCountingClientStreamTracerFactory - Class in io.grpc.util
-
Builds instances of a
ClientStreamTracer
that increments the call count in the tracker for each closed stream. - OutlierDetectionLoadBalancer.OutlierDetectionSubchannel - Class in io.grpc.util
- OutlierDetectionLoadBalancer.OutlierDetectionSubchannel.OutlierDetectionSubchannelStateListener - Class in io.grpc.util
-
Wraps the actual listener so that state changes from the actual one can be intercepted.
- OutlierDetectionLoadBalancer.OutlierEjectionAlgorithm - Interface in io.grpc.util
-
Implementations provide different ways of ejecting outlier addresses..
- OutlierDetectionLoadBalancer.SuccessRateOutlierEjectionAlgorithm - Class in io.grpc.util
-
This algorithm ejects addresses that don't maintain a required rate of successful calls.
- OutlierDetectionLoadBalancerConfig(Long, Long, Long, Integer, OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig.SuccessRateEjection, OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig.FailurePercentageEjection, Object) - Constructor for class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig
- OutlierDetectionLoadBalancerProvider - Class in io.grpc.util
- OutlierDetectionLoadBalancerProvider() - Constructor for class io.grpc.util.OutlierDetectionLoadBalancerProvider
- OutlierDetectionPicker(LoadBalancer.SubchannelPicker) - Constructor for class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionPicker
- OutlierDetectionSubchannel(LoadBalancer.CreateSubchannelArgs, LoadBalancer.Helper) - Constructor for class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionSubchannel
- OutlierDetectionSubchannelStateListener(LoadBalancer.SubchannelStateListener) - Constructor for class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionSubchannel.OutlierDetectionSubchannelStateListener
- outPath - Variable in class io.grpc.protobuf.services.TempFileSink
- outputStreamAdapter - Variable in class io.grpc.internal.MessageFramer
- OutputStreamAdapter() - Constructor for class io.grpc.internal.MessageFramer.OutputStreamAdapter
- outstandingControlFrames - Variable in class io.grpc.netty.Http2ControlFrameLimitEncoder
- outstandingControlFramesListener - Variable in class io.grpc.netty.Http2ControlFrameLimitEncoder
- overrideAuthority - Variable in class io.grpc.NameResolver.Args.Builder
- overrideAuthority - Variable in class io.grpc.NameResolver.Args
- overrideAuthority(String) - Method in class io.grpc.ForwardingChannelBuilder
- overrideAuthority(String) - Method in class io.grpc.ForwardingChannelBuilder2
- overrideAuthority(String) - Method in class io.grpc.internal.ManagedChannelImplBuilder
- overrideAuthority(String) - Method in class io.grpc.ManagedChannelBuilder
-
Overrides the authority used with TLS and HTTP virtual hosting.
- overrideProxy(String) - Static method in class io.grpc.internal.ProxyDetectorImpl
-
GRPC_PROXY_EXP is deprecated but let's maintain compatibility for now.
- overrideProxyAddress - Variable in class io.grpc.internal.ProxyDetectorImpl
- Overview - Search tag in class io.grpc.LoadBalancer
- Section
P
- panic(Throwable) - Method in class io.grpc.internal.ManagedChannelImpl
- panicMode - Variable in class io.grpc.internal.ManagedChannelImpl
- parentListener - Variable in class io.grpc.Context.CancellableContext
- parkingThread - Variable in class io.grpc.servlet.AsyncServletOutputStreamWriter
- parkingThread - Variable in class io.grpc.servlet.jakarta.AsyncServletOutputStreamWriter
- 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. - parse(InputStream) - Method in class io.grpc.protobuf.lite.ProtoLiteUtils.MessageMarshaller
- parse(InputStream) - Method in class io.grpc.protobuf.services.BinaryLogProvider.ByteArrayMarshaller
- parse(String) - Static method in class io.grpc.internal.JsonParser
-
Parses a json string, returning either a
Map<String, ?>
,List<?>
,String
,Double
,Boolean
, ornull
. - parse(String) - Static method in class io.grpc.internal.SpiffeUtil
-
Parses a URI string, applies validation rules described in SPIFFE standard, and, in case of success, returns parsed TrustDomain and Path.
- parseAsciiString(byte[]) - Method in class io.grpc.internal.GrpcUtil.AcceptEncodingMarshaller
- parseAsciiString(byte[]) - Method in interface io.grpc.Metadata.TrustedAsciiMarshaller
-
Parse a serialized metadata value from an ASCII string.
- parseAsciiString(byte[]) - Method in class io.grpc.Status.StatusCodeMarshaller
- parseAsciiString(byte[]) - Method in class io.grpc.Status.StatusMessageMarshaller
- parseAsciiString(String) - Method in class io.grpc.internal.GrpcUtil.TimeoutMarshaller
- parseAsciiString(String) - Method in interface io.grpc.Metadata.AsciiMarshaller
-
Parse a serialized metadata value from an ASCII string.
- parseAsciiStringSlow(byte[]) - Static method in class io.grpc.Status.StatusMessageMarshaller
- parseAuthority(String) - Static method in class io.grpc.netty.ProtocolNegotiators
- parseBytes(byte[]) - Method in class io.grpc.Metadata.AsciiKey
- parseBytes(byte[]) - Method in class io.grpc.Metadata.BinaryKey
- parseBytes(byte[]) - Method in interface io.grpc.Metadata.BinaryMarshaller
-
Parse a serialized metadata value from bytes.
- parseBytes(byte[]) - Method in class io.grpc.Metadata.Key
-
Parse a serialized metadata value from bytes.
- parseBytes(byte[]) - Method in class io.grpc.Metadata.LazyStreamBinaryKey
- parseBytes(byte[]) - Method in class io.grpc.Metadata.TrustedAsciiKey
- parseBytes(byte[]) - Method in class io.grpc.protobuf.lite.ProtoLiteUtils.MetadataMarshaller
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.binarylog.v1.Address
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.binarylog.v1.ClientHeader
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.binarylog.v1.GrpcLogEntry
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.binarylog.v1.Message
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.binarylog.v1.Metadata
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.binarylog.v1.MetadataEntry
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.binarylog.v1.ServerHeader
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.binarylog.v1.Trailer
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.channelz.v1.Address.OtherAddress
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.channelz.v1.Address
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.channelz.v1.Address.TcpIpAddress
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.channelz.v1.Address.UdsAddress
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.channelz.v1.Channel
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.channelz.v1.ChannelConnectivityState
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.channelz.v1.ChannelData
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.channelz.v1.ChannelRef
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.channelz.v1.ChannelTrace
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.channelz.v1.ChannelTraceEvent
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.channelz.v1.GetChannelRequest
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.channelz.v1.GetChannelResponse
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.channelz.v1.GetServerRequest
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.channelz.v1.GetServerResponse
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.channelz.v1.GetServerSocketsRequest
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.channelz.v1.GetServerSocketsResponse
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.channelz.v1.GetServersRequest
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.channelz.v1.GetServersResponse
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.channelz.v1.GetSocketRequest
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.channelz.v1.GetSocketResponse
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.channelz.v1.GetSubchannelRequest
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.channelz.v1.GetSubchannelResponse
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.channelz.v1.GetTopChannelsRequest
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.channelz.v1.GetTopChannelsResponse
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.channelz.v1.Security.OtherSecurity
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.channelz.v1.Security
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.channelz.v1.Security.Tls
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.channelz.v1.Server
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.channelz.v1.ServerData
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.channelz.v1.ServerRef
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.channelz.v1.Socket
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.channelz.v1.SocketData
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.channelz.v1.SocketOption
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.channelz.v1.SocketOptionLinger
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.channelz.v1.SocketOptionTcpInfo
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.channelz.v1.SocketOptionTimeout
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.channelz.v1.SocketRef
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.channelz.v1.Subchannel
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.channelz.v1.SubchannelRef
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.health.v1.HealthCheckRequest
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.health.v1.HealthCheckResponse
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.lb.v1.ClientStats
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.lb.v1.ClientStatsPerToken
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.lb.v1.FallbackResponse
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.lb.v1.InitialLoadBalanceRequest
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.lb.v1.InitialLoadBalanceResponse
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.lb.v1.LoadBalanceRequest
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.lb.v1.LoadBalanceResponse
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.lb.v1.Server
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.lb.v1.ServerList
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.lookup.v1.GrpcKeyBuilder.Name
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.lookup.v1.GrpcKeyBuilder
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.lookup.v1.HttpKeyBuilder
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.lookup.v1.NameMatcher
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.lookup.v1.RouteLookupClusterSpecifier
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.lookup.v1.RouteLookupConfig
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.lookup.v1.RouteLookupRequest
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.lookup.v1.RouteLookupResponse
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.reflection.v1.ErrorResponse
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.reflection.v1.ExtensionNumberResponse
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.reflection.v1.ExtensionRequest
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.reflection.v1.FileDescriptorResponse
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.reflection.v1.ListServiceResponse
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.reflection.v1.ServerReflectionRequest
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.reflection.v1.ServerReflectionResponse
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.reflection.v1.ServiceResponse
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.reflection.v1alpha.ErrorResponse
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.reflection.v1alpha.ExtensionNumberResponse
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.reflection.v1alpha.ExtensionRequest
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.reflection.v1alpha.FileDescriptorResponse
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.reflection.v1alpha.ListServiceResponse
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.reflection.v1alpha.ServerReflectionRequest
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.reflection.v1alpha.ServerReflectionResponse
- parseDelimitedFrom(InputStream) - Static method in class io.grpc.reflection.v1alpha.ServiceResponse
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.binarylog.v1.Address
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.binarylog.v1.ClientHeader
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.binarylog.v1.GrpcLogEntry
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.binarylog.v1.Message
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.binarylog.v1.Metadata
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.binarylog.v1.MetadataEntry
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.binarylog.v1.ServerHeader
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.binarylog.v1.Trailer
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.Address.OtherAddress
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.Address
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.Address.TcpIpAddress
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.Address.UdsAddress
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.Channel
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.ChannelConnectivityState
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.ChannelData
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.ChannelRef
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.ChannelTrace
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.ChannelTraceEvent
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetChannelRequest
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetChannelResponse
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetServerRequest
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetServerResponse
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetServerSocketsRequest
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetServerSocketsResponse
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetServersRequest
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetServersResponse
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetSocketRequest
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetSocketResponse
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetSubchannelRequest
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetSubchannelResponse
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetTopChannelsRequest
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetTopChannelsResponse
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.Security.OtherSecurity
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.Security
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.Security.Tls
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.Server
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.ServerData
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.ServerRef
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.Socket
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.SocketData
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.SocketOption
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.SocketOptionLinger
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.SocketOptionTcpInfo
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.SocketOptionTimeout
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.SocketRef
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.Subchannel
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.SubchannelRef
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.health.v1.HealthCheckRequest
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.health.v1.HealthCheckResponse
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.lb.v1.ClientStats
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.lb.v1.ClientStatsPerToken
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.lb.v1.FallbackResponse
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.lb.v1.InitialLoadBalanceRequest
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.lb.v1.InitialLoadBalanceResponse
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.lb.v1.LoadBalanceRequest
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.lb.v1.LoadBalanceResponse
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.lb.v1.Server
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.lb.v1.ServerList
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.lookup.v1.GrpcKeyBuilder.Name
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.lookup.v1.GrpcKeyBuilder
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.lookup.v1.HttpKeyBuilder
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.lookup.v1.NameMatcher
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.lookup.v1.RouteLookupClusterSpecifier
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.lookup.v1.RouteLookupConfig
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.lookup.v1.RouteLookupRequest
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.lookup.v1.RouteLookupResponse
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1.ErrorResponse
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1.ExtensionNumberResponse
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1.ExtensionRequest
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1.FileDescriptorResponse
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1.ListServiceResponse
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1.ServerReflectionRequest
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1.ServerReflectionResponse
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1.ServiceResponse
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1alpha.ErrorResponse
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1alpha.ExtensionNumberResponse
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1alpha.ExtensionRequest
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1alpha.FileDescriptorResponse
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1alpha.ListServiceResponse
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1alpha.ServerReflectionRequest
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1alpha.ServerReflectionResponse
- parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1alpha.ServiceResponse
- parseDuration(String) - Static method in class io.grpc.internal.JsonUtil
-
Parse from a string to produce a duration.
- parsedValue(Metadata.BinaryStreamMarshaller<T>, T) - Static method in class io.grpc.InternalMetadata
-
Creates a holder for a pre-parsed value read by the transport.
- parseFrom(byte[]) - Static method in class io.grpc.binarylog.v1.Address
- parseFrom(byte[]) - Static method in class io.grpc.binarylog.v1.ClientHeader
- parseFrom(byte[]) - Static method in class io.grpc.binarylog.v1.GrpcLogEntry
- parseFrom(byte[]) - Static method in class io.grpc.binarylog.v1.Message
- parseFrom(byte[]) - Static method in class io.grpc.binarylog.v1.Metadata
- parseFrom(byte[]) - Static method in class io.grpc.binarylog.v1.MetadataEntry
- parseFrom(byte[]) - Static method in class io.grpc.binarylog.v1.ServerHeader
- parseFrom(byte[]) - Static method in class io.grpc.binarylog.v1.Trailer
- parseFrom(byte[]) - Static method in class io.grpc.channelz.v1.Address.OtherAddress
- parseFrom(byte[]) - Static method in class io.grpc.channelz.v1.Address
- parseFrom(byte[]) - Static method in class io.grpc.channelz.v1.Address.TcpIpAddress
- parseFrom(byte[]) - Static method in class io.grpc.channelz.v1.Address.UdsAddress
- parseFrom(byte[]) - Static method in class io.grpc.channelz.v1.Channel
- parseFrom(byte[]) - Static method in class io.grpc.channelz.v1.ChannelConnectivityState
- parseFrom(byte[]) - Static method in class io.grpc.channelz.v1.ChannelData
- parseFrom(byte[]) - Static method in class io.grpc.channelz.v1.ChannelRef
- parseFrom(byte[]) - Static method in class io.grpc.channelz.v1.ChannelTrace
- parseFrom(byte[]) - Static method in class io.grpc.channelz.v1.ChannelTraceEvent
- parseFrom(byte[]) - Static method in class io.grpc.channelz.v1.GetChannelRequest
- parseFrom(byte[]) - Static method in class io.grpc.channelz.v1.GetChannelResponse
- parseFrom(byte[]) - Static method in class io.grpc.channelz.v1.GetServerRequest
- parseFrom(byte[]) - Static method in class io.grpc.channelz.v1.GetServerResponse
- parseFrom(byte[]) - Static method in class io.grpc.channelz.v1.GetServerSocketsRequest
- parseFrom(byte[]) - Static method in class io.grpc.channelz.v1.GetServerSocketsResponse
- parseFrom(byte[]) - Static method in class io.grpc.channelz.v1.GetServersRequest
- parseFrom(byte[]) - Static method in class io.grpc.channelz.v1.GetServersResponse
- parseFrom(byte[]) - Static method in class io.grpc.channelz.v1.GetSocketRequest
- parseFrom(byte[]) - Static method in class io.grpc.channelz.v1.GetSocketResponse
- parseFrom(byte[]) - Static method in class io.grpc.channelz.v1.GetSubchannelRequest
- parseFrom(byte[]) - Static method in class io.grpc.channelz.v1.GetSubchannelResponse
- parseFrom(byte[]) - Static method in class io.grpc.channelz.v1.GetTopChannelsRequest
- parseFrom(byte[]) - Static method in class io.grpc.channelz.v1.GetTopChannelsResponse
- parseFrom(byte[]) - Static method in class io.grpc.channelz.v1.Security.OtherSecurity
- parseFrom(byte[]) - Static method in class io.grpc.channelz.v1.Security
- parseFrom(byte[]) - Static method in class io.grpc.channelz.v1.Security.Tls
- parseFrom(byte[]) - Static method in class io.grpc.channelz.v1.Server
- parseFrom(byte[]) - Static method in class io.grpc.channelz.v1.ServerData
- parseFrom(byte[]) - Static method in class io.grpc.channelz.v1.ServerRef
- parseFrom(byte[]) - Static method in class io.grpc.channelz.v1.Socket
- parseFrom(byte[]) - Static method in class io.grpc.channelz.v1.SocketData
- parseFrom(byte[]) - Static method in class io.grpc.channelz.v1.SocketOption
- parseFrom(byte[]) - Static method in class io.grpc.channelz.v1.SocketOptionLinger
- parseFrom(byte[]) - Static method in class io.grpc.channelz.v1.SocketOptionTcpInfo
- parseFrom(byte[]) - Static method in class io.grpc.channelz.v1.SocketOptionTimeout
- parseFrom(byte[]) - Static method in class io.grpc.channelz.v1.SocketRef
- parseFrom(byte[]) - Static method in class io.grpc.channelz.v1.Subchannel
- parseFrom(byte[]) - Static method in class io.grpc.channelz.v1.SubchannelRef
- parseFrom(byte[]) - Static method in class io.grpc.health.v1.HealthCheckRequest
- parseFrom(byte[]) - Static method in class io.grpc.health.v1.HealthCheckResponse
- parseFrom(byte[]) - Static method in class io.grpc.lb.v1.ClientStats
- parseFrom(byte[]) - Static method in class io.grpc.lb.v1.ClientStatsPerToken
- parseFrom(byte[]) - Static method in class io.grpc.lb.v1.FallbackResponse
- parseFrom(byte[]) - Static method in class io.grpc.lb.v1.InitialLoadBalanceRequest
- parseFrom(byte[]) - Static method in class io.grpc.lb.v1.InitialLoadBalanceResponse
- parseFrom(byte[]) - Static method in class io.grpc.lb.v1.LoadBalanceRequest
- parseFrom(byte[]) - Static method in class io.grpc.lb.v1.LoadBalanceResponse
- parseFrom(byte[]) - Static method in class io.grpc.lb.v1.Server
- parseFrom(byte[]) - Static method in class io.grpc.lb.v1.ServerList
- parseFrom(byte[]) - Static method in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys
- parseFrom(byte[]) - Static method in class io.grpc.lookup.v1.GrpcKeyBuilder.Name
- parseFrom(byte[]) - Static method in class io.grpc.lookup.v1.GrpcKeyBuilder
- parseFrom(byte[]) - Static method in class io.grpc.lookup.v1.HttpKeyBuilder
- parseFrom(byte[]) - Static method in class io.grpc.lookup.v1.NameMatcher
- parseFrom(byte[]) - Static method in class io.grpc.lookup.v1.RouteLookupClusterSpecifier
- parseFrom(byte[]) - Static method in class io.grpc.lookup.v1.RouteLookupConfig
- parseFrom(byte[]) - Static method in class io.grpc.lookup.v1.RouteLookupRequest
- parseFrom(byte[]) - Static method in class io.grpc.lookup.v1.RouteLookupResponse
- parseFrom(byte[]) - Static method in class io.grpc.reflection.v1.ErrorResponse
- parseFrom(byte[]) - Static method in class io.grpc.reflection.v1.ExtensionNumberResponse
- parseFrom(byte[]) - Static method in class io.grpc.reflection.v1.ExtensionRequest
- parseFrom(byte[]) - Static method in class io.grpc.reflection.v1.FileDescriptorResponse
- parseFrom(byte[]) - Static method in class io.grpc.reflection.v1.ListServiceResponse
- parseFrom(byte[]) - Static method in class io.grpc.reflection.v1.ServerReflectionRequest
- parseFrom(byte[]) - Static method in class io.grpc.reflection.v1.ServerReflectionResponse
- parseFrom(byte[]) - Static method in class io.grpc.reflection.v1.ServiceResponse
- parseFrom(byte[]) - Static method in class io.grpc.reflection.v1alpha.ErrorResponse
- parseFrom(byte[]) - Static method in class io.grpc.reflection.v1alpha.ExtensionNumberResponse
- parseFrom(byte[]) - Static method in class io.grpc.reflection.v1alpha.ExtensionRequest
- parseFrom(byte[]) - Static method in class io.grpc.reflection.v1alpha.FileDescriptorResponse
- parseFrom(byte[]) - Static method in class io.grpc.reflection.v1alpha.ListServiceResponse
- parseFrom(byte[]) - Static method in class io.grpc.reflection.v1alpha.ServerReflectionRequest
- parseFrom(byte[]) - Static method in class io.grpc.reflection.v1alpha.ServerReflectionResponse
- parseFrom(byte[]) - Static method in class io.grpc.reflection.v1alpha.ServiceResponse
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.binarylog.v1.Address
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.binarylog.v1.ClientHeader
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.binarylog.v1.GrpcLogEntry
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.binarylog.v1.Message
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.binarylog.v1.Metadata
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.binarylog.v1.MetadataEntry
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.binarylog.v1.ServerHeader
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.binarylog.v1.Trailer
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.Address.OtherAddress
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.Address
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.Address.TcpIpAddress
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.Address.UdsAddress
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.Channel
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.ChannelConnectivityState
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.ChannelData
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.ChannelRef
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.ChannelTrace
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.ChannelTraceEvent
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetChannelRequest
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetChannelResponse
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetServerRequest
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetServerResponse
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetServerSocketsRequest
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetServerSocketsResponse
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetServersRequest
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetServersResponse
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetSocketRequest
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetSocketResponse
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetSubchannelRequest
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetSubchannelResponse
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetTopChannelsRequest
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetTopChannelsResponse
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.Security.OtherSecurity
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.Security
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.Security.Tls
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.Server
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.ServerData
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.ServerRef
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.Socket
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.SocketData
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.SocketOption
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.SocketOptionLinger
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.SocketOptionTcpInfo
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.SocketOptionTimeout
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.SocketRef
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.Subchannel
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.SubchannelRef
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.health.v1.HealthCheckRequest
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.health.v1.HealthCheckResponse
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.lb.v1.ClientStats
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.lb.v1.ClientStatsPerToken
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.lb.v1.FallbackResponse
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.lb.v1.InitialLoadBalanceRequest
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.lb.v1.InitialLoadBalanceResponse
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.lb.v1.LoadBalanceRequest
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.lb.v1.LoadBalanceResponse
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.lb.v1.Server
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.lb.v1.ServerList
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.lookup.v1.GrpcKeyBuilder.Name
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.lookup.v1.GrpcKeyBuilder
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.lookup.v1.HttpKeyBuilder
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.lookup.v1.NameMatcher
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.lookup.v1.RouteLookupClusterSpecifier
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.lookup.v1.RouteLookupConfig
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.lookup.v1.RouteLookupRequest
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.lookup.v1.RouteLookupResponse
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1.ErrorResponse
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1.ExtensionNumberResponse
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1.ExtensionRequest
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1.FileDescriptorResponse
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1.ListServiceResponse
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1.ServerReflectionRequest
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1.ServerReflectionResponse
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1.ServiceResponse
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1alpha.ErrorResponse
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1alpha.ExtensionNumberResponse
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1alpha.ExtensionRequest
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1alpha.FileDescriptorResponse
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1alpha.ListServiceResponse
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1alpha.ServerReflectionRequest
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1alpha.ServerReflectionResponse
- parseFrom(byte[], ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1alpha.ServiceResponse
- parseFrom(ByteString) - Static method in class io.grpc.binarylog.v1.Address
- parseFrom(ByteString) - Static method in class io.grpc.binarylog.v1.ClientHeader
- parseFrom(ByteString) - Static method in class io.grpc.binarylog.v1.GrpcLogEntry
- parseFrom(ByteString) - Static method in class io.grpc.binarylog.v1.Message
- parseFrom(ByteString) - Static method in class io.grpc.binarylog.v1.Metadata
- parseFrom(ByteString) - Static method in class io.grpc.binarylog.v1.MetadataEntry
- parseFrom(ByteString) - Static method in class io.grpc.binarylog.v1.ServerHeader
- parseFrom(ByteString) - Static method in class io.grpc.binarylog.v1.Trailer
- parseFrom(ByteString) - Static method in class io.grpc.channelz.v1.Address.OtherAddress
- parseFrom(ByteString) - Static method in class io.grpc.channelz.v1.Address
- parseFrom(ByteString) - Static method in class io.grpc.channelz.v1.Address.TcpIpAddress
- parseFrom(ByteString) - Static method in class io.grpc.channelz.v1.Address.UdsAddress
- parseFrom(ByteString) - Static method in class io.grpc.channelz.v1.Channel
- parseFrom(ByteString) - Static method in class io.grpc.channelz.v1.ChannelConnectivityState
- parseFrom(ByteString) - Static method in class io.grpc.channelz.v1.ChannelData
- parseFrom(ByteString) - Static method in class io.grpc.channelz.v1.ChannelRef
- parseFrom(ByteString) - Static method in class io.grpc.channelz.v1.ChannelTrace
- parseFrom(ByteString) - Static method in class io.grpc.channelz.v1.ChannelTraceEvent
- parseFrom(ByteString) - Static method in class io.grpc.channelz.v1.GetChannelRequest
- parseFrom(ByteString) - Static method in class io.grpc.channelz.v1.GetChannelResponse
- parseFrom(ByteString) - Static method in class io.grpc.channelz.v1.GetServerRequest
- parseFrom(ByteString) - Static method in class io.grpc.channelz.v1.GetServerResponse
- parseFrom(ByteString) - Static method in class io.grpc.channelz.v1.GetServerSocketsRequest
- parseFrom(ByteString) - Static method in class io.grpc.channelz.v1.GetServerSocketsResponse
- parseFrom(ByteString) - Static method in class io.grpc.channelz.v1.GetServersRequest
- parseFrom(ByteString) - Static method in class io.grpc.channelz.v1.GetServersResponse
- parseFrom(ByteString) - Static method in class io.grpc.channelz.v1.GetSocketRequest
- parseFrom(ByteString) - Static method in class io.grpc.channelz.v1.GetSocketResponse
- parseFrom(ByteString) - Static method in class io.grpc.channelz.v1.GetSubchannelRequest
- parseFrom(ByteString) - Static method in class io.grpc.channelz.v1.GetSubchannelResponse
- parseFrom(ByteString) - Static method in class io.grpc.channelz.v1.GetTopChannelsRequest
- parseFrom(ByteString) - Static method in class io.grpc.channelz.v1.GetTopChannelsResponse
- parseFrom(ByteString) - Static method in class io.grpc.channelz.v1.Security.OtherSecurity
- parseFrom(ByteString) - Static method in class io.grpc.channelz.v1.Security
- parseFrom(ByteString) - Static method in class io.grpc.channelz.v1.Security.Tls
- parseFrom(ByteString) - Static method in class io.grpc.channelz.v1.Server
- parseFrom(ByteString) - Static method in class io.grpc.channelz.v1.ServerData
- parseFrom(ByteString) - Static method in class io.grpc.channelz.v1.ServerRef
- parseFrom(ByteString) - Static method in class io.grpc.channelz.v1.Socket
- parseFrom(ByteString) - Static method in class io.grpc.channelz.v1.SocketData
- parseFrom(ByteString) - Static method in class io.grpc.channelz.v1.SocketOption
- parseFrom(ByteString) - Static method in class io.grpc.channelz.v1.SocketOptionLinger
- parseFrom(ByteString) - Static method in class io.grpc.channelz.v1.SocketOptionTcpInfo
- parseFrom(ByteString) - Static method in class io.grpc.channelz.v1.SocketOptionTimeout
- parseFrom(ByteString) - Static method in class io.grpc.channelz.v1.SocketRef
- parseFrom(ByteString) - Static method in class io.grpc.channelz.v1.Subchannel
- parseFrom(ByteString) - Static method in class io.grpc.channelz.v1.SubchannelRef
- parseFrom(ByteString) - Static method in class io.grpc.health.v1.HealthCheckRequest
- parseFrom(ByteString) - Static method in class io.grpc.health.v1.HealthCheckResponse
- parseFrom(ByteString) - Static method in class io.grpc.lb.v1.ClientStats
- parseFrom(ByteString) - Static method in class io.grpc.lb.v1.ClientStatsPerToken
- parseFrom(ByteString) - Static method in class io.grpc.lb.v1.FallbackResponse
- parseFrom(ByteString) - Static method in class io.grpc.lb.v1.InitialLoadBalanceRequest
- parseFrom(ByteString) - Static method in class io.grpc.lb.v1.InitialLoadBalanceResponse
- parseFrom(ByteString) - Static method in class io.grpc.lb.v1.LoadBalanceRequest
- parseFrom(ByteString) - Static method in class io.grpc.lb.v1.LoadBalanceResponse
- parseFrom(ByteString) - Static method in class io.grpc.lb.v1.Server
- parseFrom(ByteString) - Static method in class io.grpc.lb.v1.ServerList
- parseFrom(ByteString) - Static method in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys
- parseFrom(ByteString) - Static method in class io.grpc.lookup.v1.GrpcKeyBuilder.Name
- parseFrom(ByteString) - Static method in class io.grpc.lookup.v1.GrpcKeyBuilder
- parseFrom(ByteString) - Static method in class io.grpc.lookup.v1.HttpKeyBuilder
- parseFrom(ByteString) - Static method in class io.grpc.lookup.v1.NameMatcher
- parseFrom(ByteString) - Static method in class io.grpc.lookup.v1.RouteLookupClusterSpecifier
- parseFrom(ByteString) - Static method in class io.grpc.lookup.v1.RouteLookupConfig
- parseFrom(ByteString) - Static method in class io.grpc.lookup.v1.RouteLookupRequest
- parseFrom(ByteString) - Static method in class io.grpc.lookup.v1.RouteLookupResponse
- parseFrom(ByteString) - Static method in class io.grpc.reflection.v1.ErrorResponse
- parseFrom(ByteString) - Static method in class io.grpc.reflection.v1.ExtensionNumberResponse
- parseFrom(ByteString) - Static method in class io.grpc.reflection.v1.ExtensionRequest
- parseFrom(ByteString) - Static method in class io.grpc.reflection.v1.FileDescriptorResponse
- parseFrom(ByteString) - Static method in class io.grpc.reflection.v1.ListServiceResponse
- parseFrom(ByteString) - Static method in class io.grpc.reflection.v1.ServerReflectionRequest
- parseFrom(ByteString) - Static method in class io.grpc.reflection.v1.ServerReflectionResponse
- parseFrom(ByteString) - Static method in class io.grpc.reflection.v1.ServiceResponse
- parseFrom(ByteString) - Static method in class io.grpc.reflection.v1alpha.ErrorResponse
- parseFrom(ByteString) - Static method in class io.grpc.reflection.v1alpha.ExtensionNumberResponse
- parseFrom(ByteString) - Static method in class io.grpc.reflection.v1alpha.ExtensionRequest
- parseFrom(ByteString) - Static method in class io.grpc.reflection.v1alpha.FileDescriptorResponse
- parseFrom(ByteString) - Static method in class io.grpc.reflection.v1alpha.ListServiceResponse
- parseFrom(ByteString) - Static method in class io.grpc.reflection.v1alpha.ServerReflectionRequest
- parseFrom(ByteString) - Static method in class io.grpc.reflection.v1alpha.ServerReflectionResponse
- parseFrom(ByteString) - Static method in class io.grpc.reflection.v1alpha.ServiceResponse
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.binarylog.v1.Address
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.binarylog.v1.ClientHeader
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.binarylog.v1.GrpcLogEntry
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.binarylog.v1.Message
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.binarylog.v1.Metadata
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.binarylog.v1.MetadataEntry
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.binarylog.v1.ServerHeader
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.binarylog.v1.Trailer
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.Address.OtherAddress
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.Address
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.Address.TcpIpAddress
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.Address.UdsAddress
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.Channel
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.ChannelConnectivityState
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.ChannelData
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.ChannelRef
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.ChannelTrace
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.ChannelTraceEvent
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetChannelRequest
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetChannelResponse
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetServerRequest
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetServerResponse
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetServerSocketsRequest
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetServerSocketsResponse
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetServersRequest
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetServersResponse
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetSocketRequest
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetSocketResponse
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetSubchannelRequest
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetSubchannelResponse
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetTopChannelsRequest
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetTopChannelsResponse
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.Security.OtherSecurity
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.Security
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.Security.Tls
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.Server
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.ServerData
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.ServerRef
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.Socket
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.SocketData
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.SocketOption
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.SocketOptionLinger
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.SocketOptionTcpInfo
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.SocketOptionTimeout
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.SocketRef
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.Subchannel
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.SubchannelRef
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.health.v1.HealthCheckRequest
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.health.v1.HealthCheckResponse
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.lb.v1.ClientStats
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.lb.v1.ClientStatsPerToken
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.lb.v1.FallbackResponse
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.lb.v1.InitialLoadBalanceRequest
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.lb.v1.InitialLoadBalanceResponse
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.lb.v1.LoadBalanceRequest
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.lb.v1.LoadBalanceResponse
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.lb.v1.Server
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.lb.v1.ServerList
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.lookup.v1.GrpcKeyBuilder.Name
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.lookup.v1.GrpcKeyBuilder
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.lookup.v1.HttpKeyBuilder
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.lookup.v1.NameMatcher
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.lookup.v1.RouteLookupClusterSpecifier
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.lookup.v1.RouteLookupConfig
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.lookup.v1.RouteLookupRequest
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.lookup.v1.RouteLookupResponse
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1.ErrorResponse
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1.ExtensionNumberResponse
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1.ExtensionRequest
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1.FileDescriptorResponse
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1.ListServiceResponse
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1.ServerReflectionRequest
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1.ServerReflectionResponse
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1.ServiceResponse
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1alpha.ErrorResponse
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1alpha.ExtensionNumberResponse
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1alpha.ExtensionRequest
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1alpha.FileDescriptorResponse
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1alpha.ListServiceResponse
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1alpha.ServerReflectionRequest
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1alpha.ServerReflectionResponse
- parseFrom(ByteString, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1alpha.ServiceResponse
- parseFrom(CodedInputStream) - Static method in class io.grpc.binarylog.v1.Address
- parseFrom(CodedInputStream) - Static method in class io.grpc.binarylog.v1.ClientHeader
- parseFrom(CodedInputStream) - Static method in class io.grpc.binarylog.v1.GrpcLogEntry
- parseFrom(CodedInputStream) - Static method in class io.grpc.binarylog.v1.Message
- parseFrom(CodedInputStream) - Static method in class io.grpc.binarylog.v1.Metadata
- parseFrom(CodedInputStream) - Static method in class io.grpc.binarylog.v1.MetadataEntry
- parseFrom(CodedInputStream) - Static method in class io.grpc.binarylog.v1.ServerHeader
- parseFrom(CodedInputStream) - Static method in class io.grpc.binarylog.v1.Trailer
- parseFrom(CodedInputStream) - Static method in class io.grpc.channelz.v1.Address.OtherAddress
- parseFrom(CodedInputStream) - Static method in class io.grpc.channelz.v1.Address
- parseFrom(CodedInputStream) - Static method in class io.grpc.channelz.v1.Address.TcpIpAddress
- parseFrom(CodedInputStream) - Static method in class io.grpc.channelz.v1.Address.UdsAddress
- parseFrom(CodedInputStream) - Static method in class io.grpc.channelz.v1.Channel
- parseFrom(CodedInputStream) - Static method in class io.grpc.channelz.v1.ChannelConnectivityState
- parseFrom(CodedInputStream) - Static method in class io.grpc.channelz.v1.ChannelData
- parseFrom(CodedInputStream) - Static method in class io.grpc.channelz.v1.ChannelRef
- parseFrom(CodedInputStream) - Static method in class io.grpc.channelz.v1.ChannelTrace
- parseFrom(CodedInputStream) - Static method in class io.grpc.channelz.v1.ChannelTraceEvent
- parseFrom(CodedInputStream) - Static method in class io.grpc.channelz.v1.GetChannelRequest
- parseFrom(CodedInputStream) - Static method in class io.grpc.channelz.v1.GetChannelResponse
- parseFrom(CodedInputStream) - Static method in class io.grpc.channelz.v1.GetServerRequest
- parseFrom(CodedInputStream) - Static method in class io.grpc.channelz.v1.GetServerResponse
- parseFrom(CodedInputStream) - Static method in class io.grpc.channelz.v1.GetServerSocketsRequest
- parseFrom(CodedInputStream) - Static method in class io.grpc.channelz.v1.GetServerSocketsResponse
- parseFrom(CodedInputStream) - Static method in class io.grpc.channelz.v1.GetServersRequest
- parseFrom(CodedInputStream) - Static method in class io.grpc.channelz.v1.GetServersResponse
- parseFrom(CodedInputStream) - Static method in class io.grpc.channelz.v1.GetSocketRequest
- parseFrom(CodedInputStream) - Static method in class io.grpc.channelz.v1.GetSocketResponse
- parseFrom(CodedInputStream) - Static method in class io.grpc.channelz.v1.GetSubchannelRequest
- parseFrom(CodedInputStream) - Static method in class io.grpc.channelz.v1.GetSubchannelResponse
- parseFrom(CodedInputStream) - Static method in class io.grpc.channelz.v1.GetTopChannelsRequest
- parseFrom(CodedInputStream) - Static method in class io.grpc.channelz.v1.GetTopChannelsResponse
- parseFrom(CodedInputStream) - Static method in class io.grpc.channelz.v1.Security.OtherSecurity
- parseFrom(CodedInputStream) - Static method in class io.grpc.channelz.v1.Security
- parseFrom(CodedInputStream) - Static method in class io.grpc.channelz.v1.Security.Tls
- parseFrom(CodedInputStream) - Static method in class io.grpc.channelz.v1.Server
- parseFrom(CodedInputStream) - Static method in class io.grpc.channelz.v1.ServerData
- parseFrom(CodedInputStream) - Static method in class io.grpc.channelz.v1.ServerRef
- parseFrom(CodedInputStream) - Static method in class io.grpc.channelz.v1.Socket
- parseFrom(CodedInputStream) - Static method in class io.grpc.channelz.v1.SocketData
- parseFrom(CodedInputStream) - Static method in class io.grpc.channelz.v1.SocketOption
- parseFrom(CodedInputStream) - Static method in class io.grpc.channelz.v1.SocketOptionLinger
- parseFrom(CodedInputStream) - Static method in class io.grpc.channelz.v1.SocketOptionTcpInfo
- parseFrom(CodedInputStream) - Static method in class io.grpc.channelz.v1.SocketOptionTimeout
- parseFrom(CodedInputStream) - Static method in class io.grpc.channelz.v1.SocketRef
- parseFrom(CodedInputStream) - Static method in class io.grpc.channelz.v1.Subchannel
- parseFrom(CodedInputStream) - Static method in class io.grpc.channelz.v1.SubchannelRef
- parseFrom(CodedInputStream) - Static method in class io.grpc.health.v1.HealthCheckRequest
- parseFrom(CodedInputStream) - Static method in class io.grpc.health.v1.HealthCheckResponse
- parseFrom(CodedInputStream) - Static method in class io.grpc.lb.v1.ClientStats
- parseFrom(CodedInputStream) - Static method in class io.grpc.lb.v1.ClientStatsPerToken
- parseFrom(CodedInputStream) - Static method in class io.grpc.lb.v1.FallbackResponse
- parseFrom(CodedInputStream) - Static method in class io.grpc.lb.v1.InitialLoadBalanceRequest
- parseFrom(CodedInputStream) - Static method in class io.grpc.lb.v1.InitialLoadBalanceResponse
- parseFrom(CodedInputStream) - Static method in class io.grpc.lb.v1.LoadBalanceRequest
- parseFrom(CodedInputStream) - Static method in class io.grpc.lb.v1.LoadBalanceResponse
- parseFrom(CodedInputStream) - Static method in class io.grpc.lb.v1.Server
- parseFrom(CodedInputStream) - Static method in class io.grpc.lb.v1.ServerList
- parseFrom(CodedInputStream) - Static method in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys
- parseFrom(CodedInputStream) - Static method in class io.grpc.lookup.v1.GrpcKeyBuilder.Name
- parseFrom(CodedInputStream) - Static method in class io.grpc.lookup.v1.GrpcKeyBuilder
- parseFrom(CodedInputStream) - Static method in class io.grpc.lookup.v1.HttpKeyBuilder
- parseFrom(CodedInputStream) - Static method in class io.grpc.lookup.v1.NameMatcher
- parseFrom(CodedInputStream) - Static method in class io.grpc.lookup.v1.RouteLookupClusterSpecifier
- parseFrom(CodedInputStream) - Static method in class io.grpc.lookup.v1.RouteLookupConfig
- parseFrom(CodedInputStream) - Static method in class io.grpc.lookup.v1.RouteLookupRequest
- parseFrom(CodedInputStream) - Static method in class io.grpc.lookup.v1.RouteLookupResponse
- parseFrom(CodedInputStream) - Method in class io.grpc.protobuf.lite.ProtoLiteUtils.MessageMarshaller
- parseFrom(CodedInputStream) - Static method in class io.grpc.reflection.v1.ErrorResponse
- parseFrom(CodedInputStream) - Static method in class io.grpc.reflection.v1.ExtensionNumberResponse
- parseFrom(CodedInputStream) - Static method in class io.grpc.reflection.v1.ExtensionRequest
- parseFrom(CodedInputStream) - Static method in class io.grpc.reflection.v1.FileDescriptorResponse
- parseFrom(CodedInputStream) - Static method in class io.grpc.reflection.v1.ListServiceResponse
- parseFrom(CodedInputStream) - Static method in class io.grpc.reflection.v1.ServerReflectionRequest
- parseFrom(CodedInputStream) - Static method in class io.grpc.reflection.v1.ServerReflectionResponse
- parseFrom(CodedInputStream) - Static method in class io.grpc.reflection.v1.ServiceResponse
- parseFrom(CodedInputStream) - Static method in class io.grpc.reflection.v1alpha.ErrorResponse
- parseFrom(CodedInputStream) - Static method in class io.grpc.reflection.v1alpha.ExtensionNumberResponse
- parseFrom(CodedInputStream) - Static method in class io.grpc.reflection.v1alpha.ExtensionRequest
- parseFrom(CodedInputStream) - Static method in class io.grpc.reflection.v1alpha.FileDescriptorResponse
- parseFrom(CodedInputStream) - Static method in class io.grpc.reflection.v1alpha.ListServiceResponse
- parseFrom(CodedInputStream) - Static method in class io.grpc.reflection.v1alpha.ServerReflectionRequest
- parseFrom(CodedInputStream) - Static method in class io.grpc.reflection.v1alpha.ServerReflectionResponse
- parseFrom(CodedInputStream) - Static method in class io.grpc.reflection.v1alpha.ServiceResponse
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.binarylog.v1.Address
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.binarylog.v1.ClientHeader
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.binarylog.v1.GrpcLogEntry
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.binarylog.v1.Message
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.binarylog.v1.Metadata
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.binarylog.v1.MetadataEntry
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.binarylog.v1.ServerHeader
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.binarylog.v1.Trailer
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.Address.OtherAddress
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.Address
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.Address.TcpIpAddress
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.Address.UdsAddress
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.Channel
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.ChannelConnectivityState
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.ChannelData
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.ChannelRef
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.ChannelTrace
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.ChannelTraceEvent
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetChannelRequest
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetChannelResponse
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetServerRequest
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetServerResponse
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetServerSocketsRequest
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetServerSocketsResponse
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetServersRequest
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetServersResponse
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetSocketRequest
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetSocketResponse
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetSubchannelRequest
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetSubchannelResponse
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetTopChannelsRequest
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetTopChannelsResponse
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.Security.OtherSecurity
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.Security
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.Security.Tls
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.Server
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.ServerData
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.ServerRef
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.Socket
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.SocketData
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.SocketOption
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.SocketOptionLinger
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.SocketOptionTcpInfo
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.SocketOptionTimeout
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.SocketRef
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.Subchannel
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.SubchannelRef
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.health.v1.HealthCheckRequest
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.health.v1.HealthCheckResponse
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.lb.v1.ClientStats
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.lb.v1.ClientStatsPerToken
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.lb.v1.FallbackResponse
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.lb.v1.InitialLoadBalanceRequest
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.lb.v1.InitialLoadBalanceResponse
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.lb.v1.LoadBalanceRequest
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.lb.v1.LoadBalanceResponse
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.lb.v1.Server
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.lb.v1.ServerList
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.lookup.v1.GrpcKeyBuilder.Name
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.lookup.v1.GrpcKeyBuilder
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.lookup.v1.HttpKeyBuilder
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.lookup.v1.NameMatcher
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.lookup.v1.RouteLookupClusterSpecifier
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.lookup.v1.RouteLookupConfig
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.lookup.v1.RouteLookupRequest
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.lookup.v1.RouteLookupResponse
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1.ErrorResponse
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1.ExtensionNumberResponse
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1.ExtensionRequest
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1.FileDescriptorResponse
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1.ListServiceResponse
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1.ServerReflectionRequest
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1.ServerReflectionResponse
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1.ServiceResponse
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1alpha.ErrorResponse
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1alpha.ExtensionNumberResponse
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1alpha.ExtensionRequest
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1alpha.FileDescriptorResponse
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1alpha.ListServiceResponse
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1alpha.ServerReflectionRequest
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1alpha.ServerReflectionResponse
- parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1alpha.ServiceResponse
- parseFrom(InputStream) - Static method in class io.grpc.binarylog.v1.Address
- parseFrom(InputStream) - Static method in class io.grpc.binarylog.v1.ClientHeader
- parseFrom(InputStream) - Static method in class io.grpc.binarylog.v1.GrpcLogEntry
- parseFrom(InputStream) - Static method in class io.grpc.binarylog.v1.Message
- parseFrom(InputStream) - Static method in class io.grpc.binarylog.v1.Metadata
- parseFrom(InputStream) - Static method in class io.grpc.binarylog.v1.MetadataEntry
- parseFrom(InputStream) - Static method in class io.grpc.binarylog.v1.ServerHeader
- parseFrom(InputStream) - Static method in class io.grpc.binarylog.v1.Trailer
- parseFrom(InputStream) - Static method in class io.grpc.channelz.v1.Address.OtherAddress
- parseFrom(InputStream) - Static method in class io.grpc.channelz.v1.Address
- parseFrom(InputStream) - Static method in class io.grpc.channelz.v1.Address.TcpIpAddress
- parseFrom(InputStream) - Static method in class io.grpc.channelz.v1.Address.UdsAddress
- parseFrom(InputStream) - Static method in class io.grpc.channelz.v1.Channel
- parseFrom(InputStream) - Static method in class io.grpc.channelz.v1.ChannelConnectivityState
- parseFrom(InputStream) - Static method in class io.grpc.channelz.v1.ChannelData
- parseFrom(InputStream) - Static method in class io.grpc.channelz.v1.ChannelRef
- parseFrom(InputStream) - Static method in class io.grpc.channelz.v1.ChannelTrace
- parseFrom(InputStream) - Static method in class io.grpc.channelz.v1.ChannelTraceEvent
- parseFrom(InputStream) - Static method in class io.grpc.channelz.v1.GetChannelRequest
- parseFrom(InputStream) - Static method in class io.grpc.channelz.v1.GetChannelResponse
- parseFrom(InputStream) - Static method in class io.grpc.channelz.v1.GetServerRequest
- parseFrom(InputStream) - Static method in class io.grpc.channelz.v1.GetServerResponse
- parseFrom(InputStream) - Static method in class io.grpc.channelz.v1.GetServerSocketsRequest
- parseFrom(InputStream) - Static method in class io.grpc.channelz.v1.GetServerSocketsResponse
- parseFrom(InputStream) - Static method in class io.grpc.channelz.v1.GetServersRequest
- parseFrom(InputStream) - Static method in class io.grpc.channelz.v1.GetServersResponse
- parseFrom(InputStream) - Static method in class io.grpc.channelz.v1.GetSocketRequest
- parseFrom(InputStream) - Static method in class io.grpc.channelz.v1.GetSocketResponse
- parseFrom(InputStream) - Static method in class io.grpc.channelz.v1.GetSubchannelRequest
- parseFrom(InputStream) - Static method in class io.grpc.channelz.v1.GetSubchannelResponse
- parseFrom(InputStream) - Static method in class io.grpc.channelz.v1.GetTopChannelsRequest
- parseFrom(InputStream) - Static method in class io.grpc.channelz.v1.GetTopChannelsResponse
- parseFrom(InputStream) - Static method in class io.grpc.channelz.v1.Security.OtherSecurity
- parseFrom(InputStream) - Static method in class io.grpc.channelz.v1.Security
- parseFrom(InputStream) - Static method in class io.grpc.channelz.v1.Security.Tls
- parseFrom(InputStream) - Static method in class io.grpc.channelz.v1.Server
- parseFrom(InputStream) - Static method in class io.grpc.channelz.v1.ServerData
- parseFrom(InputStream) - Static method in class io.grpc.channelz.v1.ServerRef
- parseFrom(InputStream) - Static method in class io.grpc.channelz.v1.Socket
- parseFrom(InputStream) - Static method in class io.grpc.channelz.v1.SocketData
- parseFrom(InputStream) - Static method in class io.grpc.channelz.v1.SocketOption
- parseFrom(InputStream) - Static method in class io.grpc.channelz.v1.SocketOptionLinger
- parseFrom(InputStream) - Static method in class io.grpc.channelz.v1.SocketOptionTcpInfo
- parseFrom(InputStream) - Static method in class io.grpc.channelz.v1.SocketOptionTimeout
- parseFrom(InputStream) - Static method in class io.grpc.channelz.v1.SocketRef
- parseFrom(InputStream) - Static method in class io.grpc.channelz.v1.Subchannel
- parseFrom(InputStream) - Static method in class io.grpc.channelz.v1.SubchannelRef
- parseFrom(InputStream) - Static method in class io.grpc.health.v1.HealthCheckRequest
- parseFrom(InputStream) - Static method in class io.grpc.health.v1.HealthCheckResponse
- parseFrom(InputStream) - Static method in class io.grpc.lb.v1.ClientStats
- parseFrom(InputStream) - Static method in class io.grpc.lb.v1.ClientStatsPerToken
- parseFrom(InputStream) - Static method in class io.grpc.lb.v1.FallbackResponse
- parseFrom(InputStream) - Static method in class io.grpc.lb.v1.InitialLoadBalanceRequest
- parseFrom(InputStream) - Static method in class io.grpc.lb.v1.InitialLoadBalanceResponse
- parseFrom(InputStream) - Static method in class io.grpc.lb.v1.LoadBalanceRequest
- parseFrom(InputStream) - Static method in class io.grpc.lb.v1.LoadBalanceResponse
- parseFrom(InputStream) - Static method in class io.grpc.lb.v1.Server
- parseFrom(InputStream) - Static method in class io.grpc.lb.v1.ServerList
- parseFrom(InputStream) - Static method in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys
- parseFrom(InputStream) - Static method in class io.grpc.lookup.v1.GrpcKeyBuilder.Name
- parseFrom(InputStream) - Static method in class io.grpc.lookup.v1.GrpcKeyBuilder
- parseFrom(InputStream) - Static method in class io.grpc.lookup.v1.HttpKeyBuilder
- parseFrom(InputStream) - Static method in class io.grpc.lookup.v1.NameMatcher
- parseFrom(InputStream) - Static method in class io.grpc.lookup.v1.RouteLookupClusterSpecifier
- parseFrom(InputStream) - Static method in class io.grpc.lookup.v1.RouteLookupConfig
- parseFrom(InputStream) - Static method in class io.grpc.lookup.v1.RouteLookupRequest
- parseFrom(InputStream) - Static method in class io.grpc.lookup.v1.RouteLookupResponse
- parseFrom(InputStream) - Static method in class io.grpc.reflection.v1.ErrorResponse
- parseFrom(InputStream) - Static method in class io.grpc.reflection.v1.ExtensionNumberResponse
- parseFrom(InputStream) - Static method in class io.grpc.reflection.v1.ExtensionRequest
- parseFrom(InputStream) - Static method in class io.grpc.reflection.v1.FileDescriptorResponse
- parseFrom(InputStream) - Static method in class io.grpc.reflection.v1.ListServiceResponse
- parseFrom(InputStream) - Static method in class io.grpc.reflection.v1.ServerReflectionRequest
- parseFrom(InputStream) - Static method in class io.grpc.reflection.v1.ServerReflectionResponse
- parseFrom(InputStream) - Static method in class io.grpc.reflection.v1.ServiceResponse
- parseFrom(InputStream) - Static method in class io.grpc.reflection.v1alpha.ErrorResponse
- parseFrom(InputStream) - Static method in class io.grpc.reflection.v1alpha.ExtensionNumberResponse
- parseFrom(InputStream) - Static method in class io.grpc.reflection.v1alpha.ExtensionRequest
- parseFrom(InputStream) - Static method in class io.grpc.reflection.v1alpha.FileDescriptorResponse
- parseFrom(InputStream) - Static method in class io.grpc.reflection.v1alpha.ListServiceResponse
- parseFrom(InputStream) - Static method in class io.grpc.reflection.v1alpha.ServerReflectionRequest
- parseFrom(InputStream) - Static method in class io.grpc.reflection.v1alpha.ServerReflectionResponse
- parseFrom(InputStream) - Static method in class io.grpc.reflection.v1alpha.ServiceResponse
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.binarylog.v1.Address
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.binarylog.v1.ClientHeader
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.binarylog.v1.GrpcLogEntry
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.binarylog.v1.Message
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.binarylog.v1.Metadata
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.binarylog.v1.MetadataEntry
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.binarylog.v1.ServerHeader
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.binarylog.v1.Trailer
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.Address.OtherAddress
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.Address
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.Address.TcpIpAddress
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.Address.UdsAddress
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.Channel
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.ChannelConnectivityState
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.ChannelData
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.ChannelRef
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.ChannelTrace
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.ChannelTraceEvent
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetChannelRequest
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetChannelResponse
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetServerRequest
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetServerResponse
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetServerSocketsRequest
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetServerSocketsResponse
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetServersRequest
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetServersResponse
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetSocketRequest
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetSocketResponse
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetSubchannelRequest
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetSubchannelResponse
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetTopChannelsRequest
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetTopChannelsResponse
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.Security.OtherSecurity
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.Security
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.Security.Tls
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.Server
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.ServerData
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.ServerRef
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.Socket
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.SocketData
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.SocketOption
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.SocketOptionLinger
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.SocketOptionTcpInfo
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.SocketOptionTimeout
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.SocketRef
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.Subchannel
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.SubchannelRef
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.health.v1.HealthCheckRequest
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.health.v1.HealthCheckResponse
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.lb.v1.ClientStats
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.lb.v1.ClientStatsPerToken
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.lb.v1.FallbackResponse
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.lb.v1.InitialLoadBalanceRequest
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.lb.v1.InitialLoadBalanceResponse
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.lb.v1.LoadBalanceRequest
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.lb.v1.LoadBalanceResponse
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.lb.v1.Server
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.lb.v1.ServerList
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.lookup.v1.GrpcKeyBuilder.Name
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.lookup.v1.GrpcKeyBuilder
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.lookup.v1.HttpKeyBuilder
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.lookup.v1.NameMatcher
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.lookup.v1.RouteLookupClusterSpecifier
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.lookup.v1.RouteLookupConfig
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.lookup.v1.RouteLookupRequest
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.lookup.v1.RouteLookupResponse
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1.ErrorResponse
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1.ExtensionNumberResponse
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1.ExtensionRequest
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1.FileDescriptorResponse
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1.ListServiceResponse
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1.ServerReflectionRequest
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1.ServerReflectionResponse
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1.ServiceResponse
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1alpha.ErrorResponse
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1alpha.ExtensionNumberResponse
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1alpha.ExtensionRequest
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1alpha.FileDescriptorResponse
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1alpha.ListServiceResponse
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1alpha.ServerReflectionRequest
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1alpha.ServerReflectionResponse
- parseFrom(InputStream, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1alpha.ServiceResponse
- parseFrom(ByteBuffer) - Static method in class io.grpc.binarylog.v1.Address
- parseFrom(ByteBuffer) - Static method in class io.grpc.binarylog.v1.ClientHeader
- parseFrom(ByteBuffer) - Static method in class io.grpc.binarylog.v1.GrpcLogEntry
- parseFrom(ByteBuffer) - Static method in class io.grpc.binarylog.v1.Message
- parseFrom(ByteBuffer) - Static method in class io.grpc.binarylog.v1.Metadata
- parseFrom(ByteBuffer) - Static method in class io.grpc.binarylog.v1.MetadataEntry
- parseFrom(ByteBuffer) - Static method in class io.grpc.binarylog.v1.ServerHeader
- parseFrom(ByteBuffer) - Static method in class io.grpc.binarylog.v1.Trailer
- parseFrom(ByteBuffer) - Static method in class io.grpc.channelz.v1.Address.OtherAddress
- parseFrom(ByteBuffer) - Static method in class io.grpc.channelz.v1.Address
- parseFrom(ByteBuffer) - Static method in class io.grpc.channelz.v1.Address.TcpIpAddress
- parseFrom(ByteBuffer) - Static method in class io.grpc.channelz.v1.Address.UdsAddress
- parseFrom(ByteBuffer) - Static method in class io.grpc.channelz.v1.Channel
- parseFrom(ByteBuffer) - Static method in class io.grpc.channelz.v1.ChannelConnectivityState
- parseFrom(ByteBuffer) - Static method in class io.grpc.channelz.v1.ChannelData
- parseFrom(ByteBuffer) - Static method in class io.grpc.channelz.v1.ChannelRef
- parseFrom(ByteBuffer) - Static method in class io.grpc.channelz.v1.ChannelTrace
- parseFrom(ByteBuffer) - Static method in class io.grpc.channelz.v1.ChannelTraceEvent
- parseFrom(ByteBuffer) - Static method in class io.grpc.channelz.v1.GetChannelRequest
- parseFrom(ByteBuffer) - Static method in class io.grpc.channelz.v1.GetChannelResponse
- parseFrom(ByteBuffer) - Static method in class io.grpc.channelz.v1.GetServerRequest
- parseFrom(ByteBuffer) - Static method in class io.grpc.channelz.v1.GetServerResponse
- parseFrom(ByteBuffer) - Static method in class io.grpc.channelz.v1.GetServerSocketsRequest
- parseFrom(ByteBuffer) - Static method in class io.grpc.channelz.v1.GetServerSocketsResponse
- parseFrom(ByteBuffer) - Static method in class io.grpc.channelz.v1.GetServersRequest
- parseFrom(ByteBuffer) - Static method in class io.grpc.channelz.v1.GetServersResponse
- parseFrom(ByteBuffer) - Static method in class io.grpc.channelz.v1.GetSocketRequest
- parseFrom(ByteBuffer) - Static method in class io.grpc.channelz.v1.GetSocketResponse
- parseFrom(ByteBuffer) - Static method in class io.grpc.channelz.v1.GetSubchannelRequest
- parseFrom(ByteBuffer) - Static method in class io.grpc.channelz.v1.GetSubchannelResponse
- parseFrom(ByteBuffer) - Static method in class io.grpc.channelz.v1.GetTopChannelsRequest
- parseFrom(ByteBuffer) - Static method in class io.grpc.channelz.v1.GetTopChannelsResponse
- parseFrom(ByteBuffer) - Static method in class io.grpc.channelz.v1.Security.OtherSecurity
- parseFrom(ByteBuffer) - Static method in class io.grpc.channelz.v1.Security
- parseFrom(ByteBuffer) - Static method in class io.grpc.channelz.v1.Security.Tls
- parseFrom(ByteBuffer) - Static method in class io.grpc.channelz.v1.Server
- parseFrom(ByteBuffer) - Static method in class io.grpc.channelz.v1.ServerData
- parseFrom(ByteBuffer) - Static method in class io.grpc.channelz.v1.ServerRef
- parseFrom(ByteBuffer) - Static method in class io.grpc.channelz.v1.Socket
- parseFrom(ByteBuffer) - Static method in class io.grpc.channelz.v1.SocketData
- parseFrom(ByteBuffer) - Static method in class io.grpc.channelz.v1.SocketOption
- parseFrom(ByteBuffer) - Static method in class io.grpc.channelz.v1.SocketOptionLinger
- parseFrom(ByteBuffer) - Static method in class io.grpc.channelz.v1.SocketOptionTcpInfo
- parseFrom(ByteBuffer) - Static method in class io.grpc.channelz.v1.SocketOptionTimeout
- parseFrom(ByteBuffer) - Static method in class io.grpc.channelz.v1.SocketRef
- parseFrom(ByteBuffer) - Static method in class io.grpc.channelz.v1.Subchannel
- parseFrom(ByteBuffer) - Static method in class io.grpc.channelz.v1.SubchannelRef
- parseFrom(ByteBuffer) - Static method in class io.grpc.health.v1.HealthCheckRequest
- parseFrom(ByteBuffer) - Static method in class io.grpc.health.v1.HealthCheckResponse
- parseFrom(ByteBuffer) - Static method in class io.grpc.lb.v1.ClientStats
- parseFrom(ByteBuffer) - Static method in class io.grpc.lb.v1.ClientStatsPerToken
- parseFrom(ByteBuffer) - Static method in class io.grpc.lb.v1.FallbackResponse
- parseFrom(ByteBuffer) - Static method in class io.grpc.lb.v1.InitialLoadBalanceRequest
- parseFrom(ByteBuffer) - Static method in class io.grpc.lb.v1.InitialLoadBalanceResponse
- parseFrom(ByteBuffer) - Static method in class io.grpc.lb.v1.LoadBalanceRequest
- parseFrom(ByteBuffer) - Static method in class io.grpc.lb.v1.LoadBalanceResponse
- parseFrom(ByteBuffer) - Static method in class io.grpc.lb.v1.Server
- parseFrom(ByteBuffer) - Static method in class io.grpc.lb.v1.ServerList
- parseFrom(ByteBuffer) - Static method in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys
- parseFrom(ByteBuffer) - Static method in class io.grpc.lookup.v1.GrpcKeyBuilder.Name
- parseFrom(ByteBuffer) - Static method in class io.grpc.lookup.v1.GrpcKeyBuilder
- parseFrom(ByteBuffer) - Static method in class io.grpc.lookup.v1.HttpKeyBuilder
- parseFrom(ByteBuffer) - Static method in class io.grpc.lookup.v1.NameMatcher
- parseFrom(ByteBuffer) - Static method in class io.grpc.lookup.v1.RouteLookupClusterSpecifier
- parseFrom(ByteBuffer) - Static method in class io.grpc.lookup.v1.RouteLookupConfig
- parseFrom(ByteBuffer) - Static method in class io.grpc.lookup.v1.RouteLookupRequest
- parseFrom(ByteBuffer) - Static method in class io.grpc.lookup.v1.RouteLookupResponse
- parseFrom(ByteBuffer) - Static method in class io.grpc.reflection.v1.ErrorResponse
- parseFrom(ByteBuffer) - Static method in class io.grpc.reflection.v1.ExtensionNumberResponse
- parseFrom(ByteBuffer) - Static method in class io.grpc.reflection.v1.ExtensionRequest
- parseFrom(ByteBuffer) - Static method in class io.grpc.reflection.v1.FileDescriptorResponse
- parseFrom(ByteBuffer) - Static method in class io.grpc.reflection.v1.ListServiceResponse
- parseFrom(ByteBuffer) - Static method in class io.grpc.reflection.v1.ServerReflectionRequest
- parseFrom(ByteBuffer) - Static method in class io.grpc.reflection.v1.ServerReflectionResponse
- parseFrom(ByteBuffer) - Static method in class io.grpc.reflection.v1.ServiceResponse
- parseFrom(ByteBuffer) - Static method in class io.grpc.reflection.v1alpha.ErrorResponse
- parseFrom(ByteBuffer) - Static method in class io.grpc.reflection.v1alpha.ExtensionNumberResponse
- parseFrom(ByteBuffer) - Static method in class io.grpc.reflection.v1alpha.ExtensionRequest
- parseFrom(ByteBuffer) - Static method in class io.grpc.reflection.v1alpha.FileDescriptorResponse
- parseFrom(ByteBuffer) - Static method in class io.grpc.reflection.v1alpha.ListServiceResponse
- parseFrom(ByteBuffer) - Static method in class io.grpc.reflection.v1alpha.ServerReflectionRequest
- parseFrom(ByteBuffer) - Static method in class io.grpc.reflection.v1alpha.ServerReflectionResponse
- parseFrom(ByteBuffer) - Static method in class io.grpc.reflection.v1alpha.ServiceResponse
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.binarylog.v1.Address
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.binarylog.v1.ClientHeader
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.binarylog.v1.GrpcLogEntry
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.binarylog.v1.Message
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.binarylog.v1.Metadata
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.binarylog.v1.MetadataEntry
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.binarylog.v1.ServerHeader
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.binarylog.v1.Trailer
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.Address.OtherAddress
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.Address
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.Address.TcpIpAddress
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.Address.UdsAddress
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.Channel
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.ChannelConnectivityState
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.ChannelData
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.ChannelRef
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.ChannelTrace
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.ChannelTraceEvent
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetChannelRequest
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetChannelResponse
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetServerRequest
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetServerResponse
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetServerSocketsRequest
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetServerSocketsResponse
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetServersRequest
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetServersResponse
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetSocketRequest
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetSocketResponse
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetSubchannelRequest
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetSubchannelResponse
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetTopChannelsRequest
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.GetTopChannelsResponse
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.Security.OtherSecurity
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.Security
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.Security.Tls
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.Server
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.ServerData
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.ServerRef
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.Socket
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.SocketData
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.SocketOption
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.SocketOptionLinger
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.SocketOptionTcpInfo
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.SocketOptionTimeout
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.SocketRef
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.Subchannel
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.SubchannelRef
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.health.v1.HealthCheckRequest
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.health.v1.HealthCheckResponse
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.lb.v1.ClientStats
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.lb.v1.ClientStatsPerToken
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.lb.v1.FallbackResponse
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.lb.v1.InitialLoadBalanceRequest
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.lb.v1.InitialLoadBalanceResponse
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.lb.v1.LoadBalanceRequest
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.lb.v1.LoadBalanceResponse
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.lb.v1.Server
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.lb.v1.ServerList
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.lookup.v1.GrpcKeyBuilder.Name
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.lookup.v1.GrpcKeyBuilder
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.lookup.v1.HttpKeyBuilder
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.lookup.v1.NameMatcher
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.lookup.v1.RouteLookupClusterSpecifier
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.lookup.v1.RouteLookupConfig
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.lookup.v1.RouteLookupRequest
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.lookup.v1.RouteLookupResponse
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1.ErrorResponse
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1.ExtensionNumberResponse
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1.ExtensionRequest
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1.FileDescriptorResponse
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1.ListServiceResponse
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1.ServerReflectionRequest
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1.ServerReflectionResponse
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1.ServiceResponse
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1alpha.ErrorResponse
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1alpha.ExtensionNumberResponse
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1alpha.ExtensionRequest
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1alpha.FileDescriptorResponse
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1alpha.ListServiceResponse
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1alpha.ServerReflectionRequest
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1alpha.ServerReflectionResponse
- parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1alpha.ServiceResponse
- parseHelper(InputStream) - Method in class io.grpc.protobuf.services.BinaryLogProvider.ByteArrayMarshaller
- parseJsonArray(JsonReader) - Static method in class io.grpc.internal.JsonParser
- parseJsonNull(JsonReader) - Static method in class io.grpc.internal.JsonParser
- parseJsonObject(JsonReader) - Static method in class io.grpc.internal.JsonParser
- parseLoadBalancerPolicy(Map<String, ?>) - Method in class io.grpc.internal.AutoConfiguredLoadBalancerFactory
-
Parses first available LoadBalancer policy from service config.
- parseLoadBalancingConfigPolicyInternal(Map<String, ?>) - Method in class io.grpc.grpclb.GrpclbLoadBalancerProvider
- parseLoadBalancingPolicyConfig(List<Map<String, ?>>) - Static method in class io.grpc.util.GracefulSwitchLoadBalancer
-
Provided a JSON list of LoadBalancingConfigs, parse it into a config to pass to GracefulSwitch.
- parseLoadBalancingPolicyConfig(List<Map<String, ?>>, LoadBalancerRegistry) - Static method in class io.grpc.util.GracefulSwitchLoadBalancer
-
Provided a JSON list of LoadBalancingConfigs, parse it into a config to pass to GracefulSwitch.
- parseLoadBalancingPolicyConfig(Map<String, ?>) - Method in class io.grpc.grpclb.GrpclbLoadBalancerProvider
- parseLoadBalancingPolicyConfig(Map<String, ?>) - Method in class io.grpc.internal.PickFirstLoadBalancerProvider
- parseLoadBalancingPolicyConfig(Map<String, ?>) - Method in class io.grpc.LoadBalancerProvider
-
Parses the config for the Load Balancing policy unpacked from the service config.
- parseLoadBalancingPolicyConfig(Map<String, ?>) - Method in class io.grpc.protobuf.services.internal.HealthCheckingRoundRobinLoadBalancerProvider
- parseLoadBalancingPolicyConfig(Map<String, ?>) - Method in class io.grpc.rls.RlsLoadBalancerProvider
- parseLoadBalancingPolicyConfig(Map<String, ?>) - Method in class io.grpc.util.OutlierDetectionLoadBalancerProvider
- parseLoadBalancingPolicyConfig(Map<String, ?>) - Method in class io.grpc.util.SecretRoundRobinLoadBalancerProvider.Provider
- parseLoadBalancingPolicyConfigInternal(Map<String, ?>) - Method in class io.grpc.util.OutlierDetectionLoadBalancerProvider
- parseNanos(String) - Static method in class io.grpc.internal.JsonUtil
-
Copy of
Timestamps.parseNanos(java.lang.String)
. - parser - Variable in class io.grpc.protobuf.lite.ProtoInputStream
- parser - Variable in class io.grpc.protobuf.lite.ProtoLiteUtils.MessageMarshaller
- parser() - Static method in class io.grpc.binarylog.v1.Address
- parser() - Static method in class io.grpc.binarylog.v1.ClientHeader
- parser() - Static method in class io.grpc.binarylog.v1.GrpcLogEntry
- parser() - Static method in class io.grpc.binarylog.v1.Message
- parser() - Static method in class io.grpc.binarylog.v1.Metadata
- parser() - Static method in class io.grpc.binarylog.v1.MetadataEntry
- parser() - Static method in class io.grpc.binarylog.v1.ServerHeader
- parser() - Static method in class io.grpc.binarylog.v1.Trailer
- parser() - Static method in class io.grpc.channelz.v1.Address.OtherAddress
- parser() - Static method in class io.grpc.channelz.v1.Address
- parser() - Static method in class io.grpc.channelz.v1.Address.TcpIpAddress
- parser() - Static method in class io.grpc.channelz.v1.Address.UdsAddress
- parser() - Static method in class io.grpc.channelz.v1.Channel
- parser() - Static method in class io.grpc.channelz.v1.ChannelConnectivityState
- parser() - Static method in class io.grpc.channelz.v1.ChannelData
- parser() - Static method in class io.grpc.channelz.v1.ChannelRef
- parser() - Static method in class io.grpc.channelz.v1.ChannelTrace
- parser() - Static method in class io.grpc.channelz.v1.ChannelTraceEvent
- parser() - Static method in class io.grpc.channelz.v1.GetChannelRequest
- parser() - Static method in class io.grpc.channelz.v1.GetChannelResponse
- parser() - Static method in class io.grpc.channelz.v1.GetServerRequest
- parser() - Static method in class io.grpc.channelz.v1.GetServerResponse
- parser() - Static method in class io.grpc.channelz.v1.GetServerSocketsRequest
- parser() - Static method in class io.grpc.channelz.v1.GetServerSocketsResponse
- parser() - Static method in class io.grpc.channelz.v1.GetServersRequest
- parser() - Static method in class io.grpc.channelz.v1.GetServersResponse
- parser() - Static method in class io.grpc.channelz.v1.GetSocketRequest
- parser() - Static method in class io.grpc.channelz.v1.GetSocketResponse
- parser() - Static method in class io.grpc.channelz.v1.GetSubchannelRequest
- parser() - Static method in class io.grpc.channelz.v1.GetSubchannelResponse
- parser() - Static method in class io.grpc.channelz.v1.GetTopChannelsRequest
- parser() - Static method in class io.grpc.channelz.v1.GetTopChannelsResponse
- parser() - Static method in class io.grpc.channelz.v1.Security.OtherSecurity
- parser() - Static method in class io.grpc.channelz.v1.Security
- parser() - Static method in class io.grpc.channelz.v1.Security.Tls
- parser() - Static method in class io.grpc.channelz.v1.Server
- parser() - Static method in class io.grpc.channelz.v1.ServerData
- parser() - Static method in class io.grpc.channelz.v1.ServerRef
- parser() - Static method in class io.grpc.channelz.v1.Socket
- parser() - Static method in class io.grpc.channelz.v1.SocketData
- parser() - Static method in class io.grpc.channelz.v1.SocketOption
- parser() - Static method in class io.grpc.channelz.v1.SocketOptionLinger
- parser() - Static method in class io.grpc.channelz.v1.SocketOptionTcpInfo
- parser() - Static method in class io.grpc.channelz.v1.SocketOptionTimeout
- parser() - Static method in class io.grpc.channelz.v1.SocketRef
- parser() - Static method in class io.grpc.channelz.v1.Subchannel
- parser() - Static method in class io.grpc.channelz.v1.SubchannelRef
- parser() - Static method in class io.grpc.health.v1.HealthCheckRequest
- parser() - Static method in class io.grpc.health.v1.HealthCheckResponse
- parser() - Static method in class io.grpc.lb.v1.ClientStats
- parser() - Static method in class io.grpc.lb.v1.ClientStatsPerToken
- parser() - Static method in class io.grpc.lb.v1.FallbackResponse
- parser() - Static method in class io.grpc.lb.v1.InitialLoadBalanceRequest
- parser() - Static method in class io.grpc.lb.v1.InitialLoadBalanceResponse
- parser() - Static method in class io.grpc.lb.v1.LoadBalanceRequest
- parser() - Static method in class io.grpc.lb.v1.LoadBalanceResponse
- parser() - Static method in class io.grpc.lb.v1.Server
- parser() - Static method in class io.grpc.lb.v1.ServerList
- parser() - Static method in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys
- parser() - Static method in class io.grpc.lookup.v1.GrpcKeyBuilder.Name
- parser() - Static method in class io.grpc.lookup.v1.GrpcKeyBuilder
- parser() - Static method in class io.grpc.lookup.v1.HttpKeyBuilder
- parser() - Static method in class io.grpc.lookup.v1.NameMatcher
- parser() - Static method in class io.grpc.lookup.v1.RouteLookupClusterSpecifier
- parser() - Static method in class io.grpc.lookup.v1.RouteLookupConfig
- parser() - Static method in class io.grpc.lookup.v1.RouteLookupRequest
- parser() - Static method in class io.grpc.lookup.v1.RouteLookupResponse
- parser() - Method in class io.grpc.protobuf.lite.ProtoInputStream
- parser() - Static method in class io.grpc.reflection.v1.ErrorResponse
- parser() - Static method in class io.grpc.reflection.v1.ExtensionNumberResponse
- parser() - Static method in class io.grpc.reflection.v1.ExtensionRequest
- parser() - Static method in class io.grpc.reflection.v1.FileDescriptorResponse
- parser() - Static method in class io.grpc.reflection.v1.ListServiceResponse
- parser() - Static method in class io.grpc.reflection.v1.ServerReflectionRequest
- parser() - Static method in class io.grpc.reflection.v1.ServerReflectionResponse
- parser() - Static method in class io.grpc.reflection.v1.ServiceResponse
- parser() - Static method in class io.grpc.reflection.v1alpha.ErrorResponse
- parser() - Static method in class io.grpc.reflection.v1alpha.ExtensionNumberResponse
- parser() - Static method in class io.grpc.reflection.v1alpha.ExtensionRequest
- parser() - Static method in class io.grpc.reflection.v1alpha.FileDescriptorResponse
- parser() - Static method in class io.grpc.reflection.v1alpha.ListServiceResponse
- parser() - Static method in class io.grpc.reflection.v1alpha.ServerReflectionRequest
- parser() - Static method in class io.grpc.reflection.v1alpha.ServerReflectionResponse
- parser() - Static method in class io.grpc.reflection.v1alpha.ServiceResponse
- PARSER - Static variable in class io.grpc.binarylog.v1.Address
- PARSER - Static variable in class io.grpc.binarylog.v1.ClientHeader
- PARSER - Static variable in class io.grpc.binarylog.v1.GrpcLogEntry
- PARSER - Static variable in class io.grpc.binarylog.v1.Message
- PARSER - Static variable in class io.grpc.binarylog.v1.Metadata
- PARSER - Static variable in class io.grpc.binarylog.v1.MetadataEntry
- PARSER - Static variable in class io.grpc.binarylog.v1.ServerHeader
- PARSER - Static variable in class io.grpc.binarylog.v1.Trailer
- PARSER - Static variable in class io.grpc.channelz.v1.Address.OtherAddress
- PARSER - Static variable in class io.grpc.channelz.v1.Address
- PARSER - Static variable in class io.grpc.channelz.v1.Address.TcpIpAddress
- PARSER - Static variable in class io.grpc.channelz.v1.Address.UdsAddress
- PARSER - Static variable in class io.grpc.channelz.v1.Channel
- PARSER - Static variable in class io.grpc.channelz.v1.ChannelConnectivityState
- PARSER - Static variable in class io.grpc.channelz.v1.ChannelData
- PARSER - Static variable in class io.grpc.channelz.v1.ChannelRef
- PARSER - Static variable in class io.grpc.channelz.v1.ChannelTrace
- PARSER - Static variable in class io.grpc.channelz.v1.ChannelTraceEvent
- PARSER - Static variable in class io.grpc.channelz.v1.GetChannelRequest
- PARSER - Static variable in class io.grpc.channelz.v1.GetChannelResponse
- PARSER - Static variable in class io.grpc.channelz.v1.GetServerRequest
- PARSER - Static variable in class io.grpc.channelz.v1.GetServerResponse
- PARSER - Static variable in class io.grpc.channelz.v1.GetServerSocketsRequest
- PARSER - Static variable in class io.grpc.channelz.v1.GetServerSocketsResponse
- PARSER - Static variable in class io.grpc.channelz.v1.GetServersRequest
- PARSER - Static variable in class io.grpc.channelz.v1.GetServersResponse
- PARSER - Static variable in class io.grpc.channelz.v1.GetSocketRequest
- PARSER - Static variable in class io.grpc.channelz.v1.GetSocketResponse
- PARSER - Static variable in class io.grpc.channelz.v1.GetSubchannelRequest
- PARSER - Static variable in class io.grpc.channelz.v1.GetSubchannelResponse
- PARSER - Static variable in class io.grpc.channelz.v1.GetTopChannelsRequest
- PARSER - Static variable in class io.grpc.channelz.v1.GetTopChannelsResponse
- PARSER - Static variable in class io.grpc.channelz.v1.Security.OtherSecurity
- PARSER - Static variable in class io.grpc.channelz.v1.Security
- PARSER - Static variable in class io.grpc.channelz.v1.Security.Tls
- PARSER - Static variable in class io.grpc.channelz.v1.Server
- PARSER - Static variable in class io.grpc.channelz.v1.ServerData
- PARSER - Static variable in class io.grpc.channelz.v1.ServerRef
- PARSER - Static variable in class io.grpc.channelz.v1.Socket
- PARSER - Static variable in class io.grpc.channelz.v1.SocketData
- PARSER - Static variable in class io.grpc.channelz.v1.SocketOption
- PARSER - Static variable in class io.grpc.channelz.v1.SocketOptionLinger
- PARSER - Static variable in class io.grpc.channelz.v1.SocketOptionTcpInfo
- PARSER - Static variable in class io.grpc.channelz.v1.SocketOptionTimeout
- PARSER - Static variable in class io.grpc.channelz.v1.SocketRef
- PARSER - Static variable in class io.grpc.channelz.v1.Subchannel
- PARSER - Static variable in class io.grpc.channelz.v1.SubchannelRef
- PARSER - Static variable in class io.grpc.health.v1.HealthCheckRequest
- PARSER - Static variable in class io.grpc.health.v1.HealthCheckResponse
- PARSER - Static variable in class io.grpc.lb.v1.ClientStats
- PARSER - Static variable in class io.grpc.lb.v1.ClientStatsPerToken
- PARSER - Static variable in class io.grpc.lb.v1.FallbackResponse
- PARSER - Static variable in class io.grpc.lb.v1.InitialLoadBalanceRequest
- PARSER - Static variable in class io.grpc.lb.v1.InitialLoadBalanceResponse
- PARSER - Static variable in class io.grpc.lb.v1.LoadBalanceRequest
- PARSER - Static variable in class io.grpc.lb.v1.LoadBalanceResponse
- PARSER - Static variable in class io.grpc.lb.v1.Server
- PARSER - Static variable in class io.grpc.lb.v1.ServerList
- PARSER - Static variable in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys
- PARSER - Static variable in class io.grpc.lookup.v1.GrpcKeyBuilder.Name
- PARSER - Static variable in class io.grpc.lookup.v1.GrpcKeyBuilder
- PARSER - Static variable in class io.grpc.lookup.v1.HttpKeyBuilder
- PARSER - Static variable in class io.grpc.lookup.v1.NameMatcher
- PARSER - Static variable in class io.grpc.lookup.v1.RouteLookupClusterSpecifier
- PARSER - Static variable in class io.grpc.lookup.v1.RouteLookupConfig
- PARSER - Static variable in class io.grpc.lookup.v1.RouteLookupRequest
- PARSER - Static variable in class io.grpc.lookup.v1.RouteLookupResponse
- PARSER - Static variable in class io.grpc.reflection.v1.ErrorResponse
- PARSER - Static variable in class io.grpc.reflection.v1.ExtensionNumberResponse
- PARSER - Static variable in class io.grpc.reflection.v1.ExtensionRequest
- PARSER - Static variable in class io.grpc.reflection.v1.FileDescriptorResponse
- PARSER - Static variable in class io.grpc.reflection.v1.ListServiceResponse
- PARSER - Static variable in class io.grpc.reflection.v1.ServerReflectionRequest
- PARSER - Static variable in class io.grpc.reflection.v1.ServerReflectionResponse
- PARSER - Static variable in class io.grpc.reflection.v1.ServiceResponse
- PARSER - Static variable in class io.grpc.reflection.v1alpha.ErrorResponse
- PARSER - Static variable in class io.grpc.reflection.v1alpha.ExtensionNumberResponse
- PARSER - Static variable in class io.grpc.reflection.v1alpha.ExtensionRequest
- PARSER - Static variable in class io.grpc.reflection.v1alpha.FileDescriptorResponse
- PARSER - Static variable in class io.grpc.reflection.v1alpha.ListServiceResponse
- PARSER - Static variable in class io.grpc.reflection.v1alpha.ServerReflectionRequest
- PARSER - Static variable in class io.grpc.reflection.v1alpha.ServerReflectionResponse
- PARSER - Static variable in class io.grpc.reflection.v1alpha.ServiceResponse
- parseRecursive(JsonReader) - Static method in class io.grpc.internal.JsonParser
- parseRequest(InputStream) - Method in class io.grpc.MethodDescriptor
-
Parse an incoming request message.
- parseResponse(InputStream) - Method in class io.grpc.MethodDescriptor
-
Parse a response payload from the given
InputStream
. - parseServiceConfig(List<String>, Random, String) - Static method in class io.grpc.internal.DnsNameResolver
- parseServiceConfig(Map<String, ?>) - Method in class io.grpc.internal.ScParser
- parseServiceConfig(Map<String, ?>) - Method in class io.grpc.NameResolver.ServiceConfigParser
-
Parses and validates the service configuration chosen by the name resolver.
- parseStream(InputStream) - Method in interface io.grpc.Metadata.BinaryStreamMarshaller
-
Parses a serialized metadata value from an
InputStream
. - parseTxtResults(List<String>) - Static method in class io.grpc.internal.DnsNameResolver
-
Parse TXT service config records as JSON.
- partial - Variable in class io.grpc.protobuf.lite.ProtoInputStream
- PartialForwardingClientCall<ReqT,
RespT> - Class in io.grpc -
A
ClientCall
which forwards all of its methods to anotherClientCall
which may have a different sendMessage() message type. - PartialForwardingClientCall() - Constructor for class io.grpc.PartialForwardingClientCall
- PartialForwardingClientCallListener<RespT> - Class in io.grpc
-
A
ClientCall.Listener
which forwards all of its methods to anotherClientCall.Listener
which may have a different parameterized type than the onMessage() message type. - PartialForwardingClientCallListener() - Constructor for class io.grpc.PartialForwardingClientCallListener
- PartialForwardingServerCall<ReqT,
RespT> - Class in io.grpc -
A
ServerCall
which forwards all of it's methods to anotherServerCall
which may have a different sendMessage() message type. - PartialForwardingServerCall() - Constructor for class io.grpc.PartialForwardingServerCall
- PartialForwardingServerCallListener<ReqT> - Class in io.grpc
-
A
ServerCall.Listener
which forwards all of its methods to anotherServerCall.Listener
which may have a different parameterized type than the onMessage() message type. - PartialForwardingServerCallListener() - Constructor for class io.grpc.PartialForwardingServerCallListener
- PartialMetricInstrument - Class in io.grpc
-
A partial implementation of the
MetricInstrument
interface. - PartialMetricInstrument(int, String, String, String, List<String>, List<String>, boolean) - Constructor for class io.grpc.PartialMetricInstrument
-
Constructs a new PartialMetricInstrument with the specified attributes.
- passThrough - Variable in class io.grpc.internal.DelayedClientCall.DelayedListener
- passThrough - Variable in class io.grpc.internal.DelayedClientCall
-
true
once realCall is valid and all pending calls have been drained. - passThrough - Variable in class io.grpc.internal.DelayedStream.DelayedStreamListener
- passThrough - Variable in class io.grpc.internal.DelayedStream
-
true
once realStream is valid and all pending calls have been drained. - passThrough - Variable in class io.grpc.internal.RetriableStream.State
-
Committed and the winning substream drained.
- password - Variable in class io.grpc.HttpConnectProxiedSocketAddress.Builder
- password - Variable in class io.grpc.HttpConnectProxiedSocketAddress
- password - Variable in class io.grpc.netty.ProtocolNegotiators.ProxyProtocolNegotiationHandler
- path - Variable in class io.grpc.internal.SpiffeUtil.SpiffeId
- path - Variable in class io.grpc.netty.GrpcHttp2HeadersUtils.GrpcHttp2RequestHeaders
- path() - Method in class io.grpc.netty.AbstractHttp2Headers
- path() - Method in class io.grpc.netty.GrpcHttp2HeadersUtils.GrpcHttp2RequestHeaders
- path(CharSequence) - Method in class io.grpc.netty.AbstractHttp2Headers
- PATH_HEADER - Static variable in class io.grpc.netty.GrpcHttp2HeadersUtils.GrpcHttp2RequestHeaders
- PATH_PATTERNS_FIELD_NUMBER - Static variable in class io.grpc.lookup.v1.HttpKeyBuilder
- pathPatterns_ - Variable in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
- pathPatterns_ - Variable in class io.grpc.lookup.v1.HttpKeyBuilder
- payload - Variable in class io.grpc.internal.AbstractClientStream.GetFramer
- payload - Variable in class io.grpc.internal.SharedResourceHolder.Instance
- payload() - Method in class io.grpc.internal.Http2Ping
-
Returns the expected ping payload for this outstanding operation.
- payload() - Method in class io.grpc.netty.AbstractNettyHandler.FlowControlPinger
- payload_ - Variable in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
- payload_ - Variable in class io.grpc.binarylog.v1.GrpcLogEntry
- PAYLOAD_NOT_SET - Enum constant in enum io.grpc.binarylog.v1.GrpcLogEntry.PayloadCase
- PAYLOAD_TRUNCATED_FIELD_NUMBER - Static variable in class io.grpc.binarylog.v1.GrpcLogEntry
- PayloadCase(int) - Constructor for enum io.grpc.binarylog.v1.GrpcLogEntry.PayloadCase
- payloadCase_ - Variable in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
- payloadCase_ - Variable in class io.grpc.binarylog.v1.GrpcLogEntry
- payloadTruncated_ - Variable in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
- payloadTruncated_ - Variable in class io.grpc.binarylog.v1.GrpcLogEntry
- peer_ - Variable in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
- peer_ - Variable in class io.grpc.binarylog.v1.GrpcLogEntry
- PEER_FIELD_NUMBER - Static variable in class io.grpc.binarylog.v1.GrpcLogEntry
- peerBuilder_ - Variable in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
- peerNotify - Variable in class io.grpc.netty.CancelServerStreamCommand
- PeerNotify() - Constructor for enum io.grpc.netty.CancelServerStreamCommand.PeerNotify
- pendingApplier - Variable in class io.grpc.internal.CallCredentialsApplyingTransportFactory.CallCredentialsApplyingTransport
- pendingBalancerFactory - Variable in class io.grpc.util.GracefulSwitchLoadBalancer
- pendingCacheEntry - Variable in class io.grpc.rls.CachingRlsLbClient.CachedRouteLookupResponse
- PendingCacheEntry(RlsProtoData.RouteLookupRequest, ListenableFuture<RlsProtoData.RouteLookupResponse>, BackoffPolicy) - Constructor for class io.grpc.rls.CachingRlsLbClient.PendingCacheEntry
- pendingCall - Variable in class io.grpc.rls.CachingRlsLbClient.PendingCacheEntry
- PendingCall(Context, MethodDescriptor<ReqT, RespT>, CallOptions) - Constructor for class io.grpc.internal.ManagedChannelImpl.RealChannel.PendingCall
- pendingCallbacks - Variable in class io.grpc.internal.DelayedClientCall.DelayedListener
- pendingCallbacks - Variable in class io.grpc.internal.DelayedStream.DelayedStreamListener
- pendingCallCache - Variable in class io.grpc.rls.CachingRlsLbClient
- PendingCallRemoval() - Constructor for class io.grpc.internal.ManagedChannelImpl.RealChannel.PendingCall.PendingCallRemoval
- pendingCalls - Variable in class io.grpc.internal.DelayedStream
- pendingCalls - Variable in class io.grpc.internal.ManagedChannelImpl
- pendingCallsInUseObject - Variable in class io.grpc.internal.ManagedChannelImpl
- pendingDeadline - Variable in class io.grpc.Context.CancellableContext
- pendingDeliveries - Variable in class io.grpc.internal.MessageDeframer
- pendingLb - Variable in class io.grpc.util.GracefulSwitchLoadBalancer
- pendingPicker - Variable in class io.grpc.util.GracefulSwitchLoadBalancer
- pendingResponse(CachingRlsLbClient.PendingCacheEntry) - Static method in class io.grpc.rls.CachingRlsLbClient.CachedRouteLookupResponse
- pendingRpcComplete(CachingRlsLbClient.PendingCacheEntry) - Method in class io.grpc.rls.CachingRlsLbClient
- pendingRunnables - Variable in class io.grpc.internal.DelayedClientCall
- pendingState - Variable in class io.grpc.util.GracefulSwitchLoadBalancer
- PendingStream(LoadBalancer.PickSubchannelArgs, ClientStreamTracer[]) - Constructor for class io.grpc.internal.DelayedClientTransport.PendingStream
- pendingStreams - Variable in class io.grpc.internal.DelayedClientTransport
- pendingToString() - Method in class io.grpc.stub.ClientCalls.GrpcFuture
- pendingTransport - Variable in class io.grpc.internal.InternalSubchannel
-
The to-be active transport, which is not ready yet.
- perAttemptRecvTimeoutNanos - Variable in class io.grpc.internal.RetryPolicy
- periodicClean() - Method in class io.grpc.rls.CachingRlsLbClient
- periodicCleaner - Variable in class io.grpc.rls.CachingRlsLbClient
- perMethodLogs - Variable in class io.grpc.protobuf.services.BinlogHelper.FactoryImpl
- PERMISSION_DENIED - Enum constant in enum io.grpc.Status.Code
-
The caller does not have permission to execute the specified operation.
- PERMISSION_DENIED - Static variable in class io.grpc.Status
-
The caller does not have permission to execute the specified operation.
- permitKeepAliveTime(long, TimeUnit) - Method in class io.grpc.ForwardingServerBuilder
- permitKeepAliveTime(long, TimeUnit) - Method in class io.grpc.netty.NettyServerBuilder
-
Specify the most aggressive keep-alive time clients are permitted to configure.
- permitKeepAliveTime(long, TimeUnit) - Method in class io.grpc.ServerBuilder
-
Specify the most aggressive keep-alive time clients are permitted to configure.
- permitKeepAliveTimeInNanos - Variable in class io.grpc.netty.NettyServer
- permitKeepAliveTimeInNanos - Variable in class io.grpc.netty.NettyServerBuilder
- permitKeepAliveTimeInNanos - Variable in class io.grpc.netty.NettyServerTransport
- permitKeepAliveWithoutCalls - Variable in class io.grpc.netty.NettyServer
- permitKeepAliveWithoutCalls - Variable in class io.grpc.netty.NettyServerBuilder
- permitKeepAliveWithoutCalls - Variable in class io.grpc.netty.NettyServerTransport
- permitKeepAliveWithoutCalls(boolean) - Method in class io.grpc.ForwardingServerBuilder
- permitKeepAliveWithoutCalls(boolean) - Method in class io.grpc.netty.NettyServerBuilder
-
Sets whether to allow clients to send keep-alive HTTP/2 PINGs even if there are no outstanding RPCs on the connection.
- permitKeepAliveWithoutCalls(boolean) - Method in class io.grpc.ServerBuilder
-
Sets whether to allow clients to send keep-alive HTTP/2 PINGs even if there are no outstanding RPCs on the connection.
- permitWithoutCalls - Variable in class io.grpc.internal.KeepAliveEnforcer
- perRpcBufferLimit - Variable in class io.grpc.internal.ManagedChannelImpl
- perRpcBufferLimit - Variable in class io.grpc.internal.ManagedChannelImplBuilder
- perRpcBufferLimit - Variable in class io.grpc.internal.RetriableStream
- perRpcBufferLimit(long) - Method in class io.grpc.ForwardingChannelBuilder
- perRpcBufferLimit(long) - Method in class io.grpc.ForwardingChannelBuilder2
- perRpcBufferLimit(long) - Method in class io.grpc.internal.ManagedChannelImplBuilder
- perRpcBufferLimit(long) - Method in class io.grpc.ManagedChannelBuilder
-
Sets the per RPC buffer limit in bytes used for retry.
- perRpcBufferUsed - Variable in class io.grpc.internal.RetriableStream
- perServerSockets - Variable in class io.grpc.InternalChannelz
- perServiceLogs - Variable in class io.grpc.protobuf.services.BinlogHelper.FactoryImpl
- PersistentHashArrayMappedTrie - Class in io.grpc
-
A persistent (copy-on-write) hash tree/trie.
- PersistentHashArrayMappedTrie() - Constructor for class io.grpc.PersistentHashArrayMappedTrie
- PersistentHashArrayMappedTrie.CollisionLeaf<K,
V> - Class in io.grpc - PersistentHashArrayMappedTrie.CompressedIndex<K,
V> - Class in io.grpc - PersistentHashArrayMappedTrie.Leaf<K,
V> - Class in io.grpc - PersistentHashArrayMappedTrie.Node<K,
V> - Interface in io.grpc - phantom - Variable in class io.grpc.internal.ManagedChannelOrphanWrapper
- PICK_FIRST - Enum constant in enum io.grpc.grpclb.GrpclbState.Mode
- pickDetailsConsumer - Variable in class io.grpc.internal.PickSubchannelArgsImpl
- PickDetailsConsumerImpl - Class in io.grpc.internal
-
Adapter for tracers into details consumers.
- PickDetailsConsumerImpl(ClientStreamTracer[]) - Constructor for class io.grpc.internal.PickDetailsConsumerImpl
-
Construct a consumer with unchanging tracers array.
- picked() - Method in class io.grpc.grpclb.GrpclbState.DropEntry
- picked(Metadata) - Method in class io.grpc.grpclb.GrpclbState.BackendEntry
- picked(Metadata) - Method in class io.grpc.grpclb.GrpclbState.ErrorEntry
- picked(Metadata) - Method in class io.grpc.grpclb.GrpclbState.IdleSubchannelEntry
- picked(Metadata) - Method in interface io.grpc.grpclb.GrpclbState.RoundRobinEntry
- picker - Variable in class io.grpc.rls.CachingRlsLbClient.RlsLbHelper
- picker - Variable in class io.grpc.rls.ChildLoadBalancerHelper.ChildLoadBalancerHelperProvider
- picker - Variable in class io.grpc.rls.ChildLoadBalancerHelper
- picker - Variable in class io.grpc.rls.LbPolicyConfiguration.ChildPolicyWrapper
- Picker(LoadBalancer.PickResult) - Constructor for class io.grpc.internal.PickFirstLeafLoadBalancer.Picker
- Picker(LoadBalancer.PickResult) - Constructor for class io.grpc.internal.PickFirstLoadBalancer.Picker
- pickerState - Variable in class io.grpc.internal.DelayedClientTransport
-
Immutable state needed for picking.
- PickerState(LoadBalancer.SubchannelPicker, Status) - Constructor for class io.grpc.internal.DelayedClientTransport.PickerState
- pickFirstLbProvider - Variable in class io.grpc.util.MultiChildLoadBalancer
- pickFirstLeafLoadBalancer - Variable in class io.grpc.internal.PickFirstLeafLoadBalancer.RequestConnectionPicker
- PickFirstLeafLoadBalancer - Class in io.grpc.internal
-
A
LoadBalancer
that provides no load-balancing over the addresses from theNameResolver
. - PickFirstLeafLoadBalancer(LoadBalancer.Helper) - Constructor for class io.grpc.internal.PickFirstLeafLoadBalancer
- PickFirstLeafLoadBalancer.HealthListener - Class in io.grpc.internal
- PickFirstLeafLoadBalancer.Index - Class in io.grpc.internal
-
Index as in 'i', the pointer to an entry.
- PickFirstLeafLoadBalancer.Picker - Class in io.grpc.internal
-
No-op picker which doesn't add any custom picking logic.
- PickFirstLeafLoadBalancer.PickFirstLeafLoadBalancerConfig - Class in io.grpc.internal
- PickFirstLeafLoadBalancer.RequestConnectionPicker - Class in io.grpc.internal
-
Picker that requests connection during the first pick, and returns noResult.
- PickFirstLeafLoadBalancer.SubchannelData - Class in io.grpc.internal
- PickFirstLeafLoadBalancerConfig(Boolean) - Constructor for class io.grpc.internal.PickFirstLeafLoadBalancer.PickFirstLeafLoadBalancerConfig
- PickFirstLeafLoadBalancerConfig(Boolean, Long) - Constructor for class io.grpc.internal.PickFirstLeafLoadBalancer.PickFirstLeafLoadBalancerConfig
- PickFirstLoadBalancer - Class in io.grpc.internal
-
A
LoadBalancer
that provides no load-balancing over the addresses from theNameResolver
. - PickFirstLoadBalancer(LoadBalancer.Helper) - Constructor for class io.grpc.internal.PickFirstLoadBalancer
- PickFirstLoadBalancer.Picker - Class in io.grpc.internal
-
No-op picker which doesn't add any custom picking logic.
- PickFirstLoadBalancer.PickFirstLoadBalancerConfig - Class in io.grpc.internal
- PickFirstLoadBalancer.RequestConnectionPicker - Class in io.grpc.internal
-
Picker that requests connection during the first pick, and returns noResult.
- PickFirstLoadBalancerConfig(Boolean) - Constructor for class io.grpc.internal.PickFirstLoadBalancer.PickFirstLoadBalancerConfig
- PickFirstLoadBalancerConfig(Boolean, Long) - Constructor for class io.grpc.internal.PickFirstLoadBalancer.PickFirstLoadBalancerConfig
- PickFirstLoadBalancerProvider - Class in io.grpc.internal
-
Provider for the "pick_first" balancing policy.
- PickFirstLoadBalancerProvider() - Constructor for class io.grpc.internal.PickFirstLoadBalancerProvider
- pickIndex - Variable in class io.grpc.grpclb.GrpclbState.RoundRobinPicker
- pickList - Variable in class io.grpc.grpclb.GrpclbState.RoundRobinPicker
- PickResult(LoadBalancer.Subchannel, ClientStreamTracer.Factory, Status, boolean) - Constructor for class io.grpc.LoadBalancer.PickResult
- pickSubchannel(LoadBalancer.PickSubchannelArgs) - Method in class io.grpc.grpclb.GrpclbState.RoundRobinPicker
- pickSubchannel(LoadBalancer.PickSubchannelArgs) - Method in class io.grpc.internal.AutoConfiguredLoadBalancerFactory.EmptyPicker
- pickSubchannel(LoadBalancer.PickSubchannelArgs) - Method in class io.grpc.internal.AutoConfiguredLoadBalancerFactory.FailingPicker
- pickSubchannel(LoadBalancer.PickSubchannelArgs) - Method in class io.grpc.internal.PickFirstLeafLoadBalancer.Picker
- pickSubchannel(LoadBalancer.PickSubchannelArgs) - Method in class io.grpc.internal.PickFirstLeafLoadBalancer.RequestConnectionPicker
- pickSubchannel(LoadBalancer.PickSubchannelArgs) - Method in class io.grpc.internal.PickFirstLoadBalancer.Picker
- pickSubchannel(LoadBalancer.PickSubchannelArgs) - Method in class io.grpc.internal.PickFirstLoadBalancer.RequestConnectionPicker
- pickSubchannel(LoadBalancer.PickSubchannelArgs) - Method in class io.grpc.LoadBalancer.ErrorPicker
-
Deprecated.
- pickSubchannel(LoadBalancer.PickSubchannelArgs) - Method in class io.grpc.LoadBalancer.FixedResultPicker
- pickSubchannel(LoadBalancer.PickSubchannelArgs) - Method in class io.grpc.LoadBalancer.SubchannelPicker
-
Make a balancing decision for a new RPC.
- pickSubchannel(LoadBalancer.PickSubchannelArgs) - Method in class io.grpc.rls.CachingRlsLbClient.RlsPicker
- pickSubchannel(LoadBalancer.PickSubchannelArgs) - Method in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionPicker
- pickSubchannel(LoadBalancer.PickSubchannelArgs) - Method in class io.grpc.util.RoundRobinLoadBalancer.ReadyPicker
- PickSubchannelArgs() - Constructor for class io.grpc.LoadBalancer.PickSubchannelArgs
- PickSubchannelArgsImpl - Class in io.grpc.internal
-
Implementation of
LoadBalancer.PickSubchannelArgs
. - PickSubchannelArgsImpl(MethodDescriptor<?, ?>, Metadata, CallOptions, LoadBalancer.PickDetailsConsumer) - Constructor for class io.grpc.internal.PickSubchannelArgsImpl
-
Creates call args object for given method with its call options, metadata.
- ping - Variable in class io.grpc.netty.NettyClientHandler
- ping() - Method in class io.grpc.internal.KeepAliveManager.ClientKeepAlivePinger
- ping() - Method in interface io.grpc.internal.KeepAliveManager.KeepAlivePinger
-
Sends out a keep-alive ping.
- ping() - Method in class io.grpc.netty.NettyServerHandler.KeepAlivePinger
- ping(ClientTransport.PingCallback, Executor) - Method in class io.grpc.inprocess.InProcessTransport
- ping(ClientTransport.PingCallback, Executor) - Method in interface io.grpc.internal.ClientTransport
-
Pings a remote endpoint.
- ping(ClientTransport.PingCallback, Executor) - Method in class io.grpc.internal.DelayedClientTransport
- ping(ClientTransport.PingCallback, Executor) - Method in class io.grpc.internal.FailingClientTransport
- ping(ClientTransport.PingCallback, Executor) - Method in class io.grpc.internal.ForwardingConnectionClientTransport
- ping(ClientTransport.PingCallback, Executor) - Method in class io.grpc.netty.NettyClientTransport
- PING_DELAYED - Enum constant in enum io.grpc.internal.KeepAliveManager.State
- PING_SCHEDULED - Enum constant in enum io.grpc.internal.KeepAliveManager.State
- PING_SENT - Enum constant in enum io.grpc.internal.KeepAliveManager.State
- pingAcceptable() - Method in class io.grpc.internal.KeepAliveEnforcer
-
Returns
false
when client is misbehaving and should be disconnected. - pingAckedOrTimeout - Variable in class io.grpc.netty.NettyServerHandler.GracefulShutdown
-
True if ping is Acked or ping is timeout.
- pingCount - Variable in class io.grpc.netty.AbstractNettyHandler.FlowControlPinger
- pingCount - Variable in class io.grpc.netty.NettyClientHandler.PingCountingFrameWriter
- PingCountingFrameWriter(Http2FrameWriter) - Constructor for class io.grpc.netty.NettyClientHandler.PingCountingFrameWriter
- pingFrequencyMultiplier - Variable in class io.grpc.netty.AbstractNettyHandler.FlowControlPinger
- pingFuture - Variable in class io.grpc.internal.KeepAliveManager
- pingFuture - Variable in class io.grpc.netty.NettyServerHandler.GracefulShutdown
- pinging - Variable in class io.grpc.netty.AbstractNettyHandler.FlowControlPinger
- pingLimiter - Variable in class io.grpc.netty.AbstractNettyHandler.FlowControlPinger
- pingReturn - Variable in class io.grpc.netty.AbstractNettyHandler.FlowControlPinger
- pingStrikes - Variable in class io.grpc.internal.KeepAliveEnforcer
- plaintext() - Static method in class io.grpc.netty.InternalProtocolNegotiators
-
Returns a
ProtocolNegotiator
for plaintext client channel. - plaintext() - Static method in class io.grpc.netty.ProtocolNegotiators
-
Returns a
ChannelHandler
that ensures that thehandler
is added to the pipeline writes to theChannel
may happen immediately, even before it is active. - PLAINTEXT - Enum constant in enum io.grpc.netty.NegotiationType
-
Just assume the connection is plaintext (non-SSL) and the remote endpoint supports HTTP/2 directly without an upgrade.
- PLAINTEXT_UPGRADE - Enum constant in enum io.grpc.netty.NegotiationType
-
Use the HTTP UPGRADE protocol for a plaintext (non-SSL) upgrade from HTTP/1.1 to HTTP/2.
- plaintextClientFactory() - Static method in class io.grpc.netty.ProtocolNegotiators
- PlaintextProtocolNegotiator() - Constructor for class io.grpc.netty.ProtocolNegotiators.PlaintextProtocolNegotiator
- PlaintextProtocolNegotiatorClientFactory() - Constructor for class io.grpc.netty.ProtocolNegotiators.PlaintextProtocolNegotiatorClientFactory
- PlaintextProtocolNegotiatorServerFactory() - Constructor for class io.grpc.netty.ProtocolNegotiators.PlaintextProtocolNegotiatorServerFactory
- plaintextUpgrade() - Static method in class io.grpc.netty.ProtocolNegotiators
-
Returns a
ProtocolNegotiator
used for upgrading to HTTP/2 from HTTP/1.x. - plaintextUpgradeClientFactory() - Static method in class io.grpc.netty.ProtocolNegotiators
- PlaintextUpgradeProtocolNegotiator() - Constructor for class io.grpc.netty.ProtocolNegotiators.PlaintextUpgradeProtocolNegotiator
- PlaintextUpgradeProtocolNegotiatorClientFactory() - Constructor for class io.grpc.netty.ProtocolNegotiators.PlaintextUpgradeProtocolNegotiatorClientFactory
- pmtu - Variable in class io.grpc.InternalChannelz.TcpInfo.Builder
- pmtu - Variable in class io.grpc.InternalChannelz.TcpInfo
- pne - Variable in class io.grpc.netty.ProtocolNegotiators.Http2UpgradeAndGrpcHandler
- pne - Variable in class io.grpc.netty.ProtocolNegotiators.ProtocolNegotiationHandler
- pne - Variable in class io.grpc.netty.ProtocolNegotiators.ServerTlsHandler
- policy - Variable in class io.grpc.internal.BackoffPolicyRetryScheduler
- policy - Variable in class io.grpc.rls.LbPolicyConfiguration
- PolicyException(String) - Constructor for exception class io.grpc.internal.AutoConfiguredLoadBalancerFactory.PolicyException
- policyName - Variable in class io.grpc.internal.ServiceConfigUtil.LbConfig
- policyProvider - Variable in class io.grpc.internal.BackoffPolicyRetryScheduler
- PolicySelection(LoadBalancerProvider, Object) - Constructor for class io.grpc.internal.ServiceConfigUtil.PolicySelection
-
Constructs a PolicySelection with selected LB provider and the deeply parsed LB config.
- pool - Variable in class io.grpc.internal.ManagedChannelImpl.ExecutorHolder
- port - Variable in class io.grpc.internal.DnsNameResolver
- port - Variable in class io.grpc.internal.DnsNameResolver.SrvRecord
- port - Variable in class io.grpc.internal.ManagedChannelImplBuilder.FixedPortProvider
- port - Variable in class io.grpc.netty.ProtocolNegotiators.ClientTlsHandler
- port - Variable in class io.grpc.netty.ProtocolNegotiators.HostPort
- port_ - Variable in class io.grpc.channelz.v1.Address.TcpIpAddress.Builder
- port_ - Variable in class io.grpc.channelz.v1.Address.TcpIpAddress
- port_ - Variable in class io.grpc.lb.v1.Server.Builder
- port_ - Variable in class io.grpc.lb.v1.Server
- PORT_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.Address.TcpIpAddress
- PORT_FIELD_NUMBER - Static variable in class io.grpc.lb.v1.Server
- postCommit() - Method in class io.grpc.internal.RetriableStream
- PREFIX - Static variable in class io.grpc.internal.SpiffeUtil
- preHeaders - Variable in class io.grpc.netty.GrpcHttp2OutboundHeaders
- prepareHeaders(Metadata, DecompressorRegistry, Compressor, boolean) - Static method in class io.grpc.internal.ClientCallImpl
- prestart() - Method in class io.grpc.internal.RetriableStream
-
Runs pre-start tasks.
- preStartPendingCalls - Variable in class io.grpc.internal.DelayedStream
- previousAttemptCount - Variable in class io.grpc.internal.RetriableStream.Substream
- previousAttempts - Variable in class io.grpc.ClientStreamTracer.StreamInfo.Builder
- previousAttempts - Variable in class io.grpc.ClientStreamTracer.StreamInfo
- prevState - Variable in class io.grpc.rls.CachingRlsLbClient.BackoffRefreshListener
- printShortStatus(Status) - Method in class io.grpc.internal.InternalSubchannel
- priority() - Method in class io.grpc.grpclb.SecretGrpclbNameResolverProvider.Provider
- priority() - Method in class io.grpc.internal.DnsNameResolverProvider
- priority() - Method in class io.grpc.internal.ManagedChannelImplBuilder.DirectAddressNameResolverProvider
- priority() - Method in class io.grpc.internal.NameResolverFactoryToProviderFacade
- 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.netty.NettyChannelProvider
- priority() - Method in class io.grpc.netty.NettyServerProvider
- priority() - Method in class io.grpc.netty.UdsNameResolverProvider
- priority() - Method in class io.grpc.netty.UdsNettyChannelProvider
- 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.
- PRIVACY_AND_INTEGRITY - Enum constant in enum io.grpc.SecurityLevel
-
In addition to
INTEGRITY
, the data is only visible to the intended communication parties. - privateKey - Variable in class io.grpc.TlsChannelCredentials.Builder
- privateKey - Variable in class io.grpc.TlsChannelCredentials
- privateKey - Variable in class io.grpc.TlsServerCredentials.Builder
- privateKey - Variable in class io.grpc.TlsServerCredentials
- privateKeyPassword - Variable in class io.grpc.TlsChannelCredentials.Builder
- privateKeyPassword - Variable in class io.grpc.TlsChannelCredentials
- privateKeyPassword - Variable in class io.grpc.TlsServerCredentials.Builder
- privateKeyPassword - Variable in class io.grpc.TlsServerCredentials
- probes - Variable in class io.grpc.InternalChannelz.TcpInfo.Builder
- probes - Variable in class io.grpc.InternalChannelz.TcpInfo
- processBody() - Method in class io.grpc.internal.MessageDeframer
-
Processes the GRPC message body, which depending on frame header flags may be compressed.
- PROCESSED - Enum constant in enum io.grpc.internal.ClientStreamListener.RpcProgress
-
The RPC may have been processed by the server.
- processExtension(Descriptors.FieldDescriptor, Descriptors.FileDescriptor) - Method in class io.grpc.protobuf.services.ProtoReflectionServiceV1.FileDescriptorIndex
- processFileDescriptor(Descriptors.FileDescriptor) - Method in class io.grpc.protobuf.services.ProtoReflectionServiceV1.FileDescriptorIndex
- processHeader() - Method in class io.grpc.internal.GzipInflatingBuffer
- processHeader() - Method in class io.grpc.internal.MessageDeframer
-
Processes the GRPC compression header which is composed of the compression flag and the outer frame length.
- processHeaderComment() - Method in class io.grpc.internal.GzipInflatingBuffer
- processHeaderCrc() - Method in class io.grpc.internal.GzipInflatingBuffer
- processHeaderExtra() - Method in class io.grpc.internal.GzipInflatingBuffer
- processHeaderExtraLen() - Method in class io.grpc.internal.GzipInflatingBuffer
- processHeaderName() - Method in class io.grpc.internal.GzipInflatingBuffer
- processService(Descriptors.ServiceDescriptor, Descriptors.FileDescriptor) - Method in class io.grpc.protobuf.services.ProtoReflectionServiceV1.FileDescriptorIndex
- processSubchannelState(PickFirstLeafLoadBalancer.SubchannelData, ConnectivityStateInfo) - Method in class io.grpc.internal.PickFirstLeafLoadBalancer
- processSubchannelState(LoadBalancer.Subchannel, ConnectivityStateInfo) - Method in class io.grpc.internal.PickFirstLoadBalancer
- processTrailer() - Method in class io.grpc.internal.GzipInflatingBuffer
- processType(Descriptors.Descriptor, Descriptors.FileDescriptor) - Method in class io.grpc.protobuf.services.ProtoReflectionServiceV1.FileDescriptorIndex
- producedSocketAddressTypes - Variable in class io.grpc.internal.ManagedChannelImplBuilder.DirectAddressNameResolverProvider
- progress - Variable in class io.grpc.internal.RetriableStream.SavedCloseMasterListenerReason
- promise - Variable in class io.grpc.netty.SendGrpcFrameCommand
- promise - Variable in class io.grpc.netty.WriteBufferingAndExceptionHandler.ChannelWrite
- promise - Variable in class io.grpc.netty.WriteQueue.AbstractQueuedCommand
- promise() - Method in class io.grpc.netty.SendGrpcFrameCommand
- promise() - Method in class io.grpc.netty.WriteQueue.AbstractQueuedCommand
- promise() - Method in interface io.grpc.netty.WriteQueue.QueuedCommand
-
Returns the promise beeing notified of the success/failure of the write.
- promise() - Method in class io.grpc.netty.WriteQueue.RunnableCommand
- promise(ChannelPromise) - Method in class io.grpc.netty.SendGrpcFrameCommand
- promise(ChannelPromise) - Method in class io.grpc.netty.WriteQueue.AbstractQueuedCommand
- promise(ChannelPromise) - Method in interface io.grpc.netty.WriteQueue.QueuedCommand
-
Sets the promise.
- promise(ChannelPromise) - Method in class io.grpc.netty.WriteQueue.RunnableCommand
- propagateCauseWithStatus(boolean) - Method in class io.grpc.inprocess.InProcessChannelBuilder
-
Sets whether to include the cause with the status that is propagated forward from the InProcessTransport.
- propagateError(Status) - Method in class io.grpc.grpclb.GrpclbState
- propagateTlsComplete(ChannelHandlerContext, SSLSession) - Method in class io.grpc.netty.ProtocolNegotiators.ClientTlsHandler
- proto - Variable in class io.grpc.protobuf.services.BinlogHelper.MaybeTruncated
- PROTOCOL_ERROR - Enum constant in enum io.grpc.internal.GrpcUtil.Http2Error
- ProtocolNegotiationEvent - Class in io.grpc.netty
-
Represents a completion of a protocol negotiation stage.
- ProtocolNegotiationEvent(Attributes, InternalChannelz.Security) - Constructor for class io.grpc.netty.ProtocolNegotiationEvent
- protocolNegotiationEventReceived - Variable in class io.grpc.netty.ProtocolNegotiators.WaitUntilActiveHandler
- protocolNegotiationEventTriggered(ChannelHandlerContext) - Method in class io.grpc.netty.ProtocolNegotiators.ProtocolNegotiationHandler
- protocolNegotiationEventTriggered(ChannelHandlerContext) - Method in class io.grpc.netty.ProtocolNegotiators.ProxyProtocolNegotiationHandler
- protocolNegotiationEventTriggered(ChannelHandlerContext) - Method in class io.grpc.netty.ProtocolNegotiators.WaitUntilActiveHandler
- ProtocolNegotiationHandler(ChannelHandler, ChannelLogger) - Constructor for class io.grpc.netty.InternalProtocolNegotiators.ProtocolNegotiationHandler
- ProtocolNegotiationHandler(ChannelHandler, ChannelLogger) - Constructor for class io.grpc.netty.ProtocolNegotiators.ProtocolNegotiationHandler
- ProtocolNegotiationHandler(ChannelHandler, String, ChannelLogger) - Constructor for class io.grpc.netty.InternalProtocolNegotiators.ProtocolNegotiationHandler
- ProtocolNegotiationHandler(ChannelHandler, String, ChannelLogger) - Constructor for class io.grpc.netty.ProtocolNegotiators.ProtocolNegotiationHandler
- protocolNegotiator - Variable in class io.grpc.netty.NettyChannelBuilder.NettyTransportFactory
- protocolNegotiator - Variable in class io.grpc.netty.NettyServer
- protocolNegotiator - Variable in class io.grpc.netty.NettyServerTransport
- protocolNegotiator - Variable in class io.grpc.netty.ProtocolNegotiators.FixedProtocolNegotiatorServerFactory
- protocolNegotiator(ProtocolNegotiator) - Method in class io.grpc.netty.NettyServerBuilder
-
Sets the
ProtocolNegotiator
to be used. - ProtocolNegotiator - Interface in io.grpc.netty
-
An class that provides a Netty handler to control protocol negotiation.
- ProtocolNegotiator.ClientFactory - Interface in io.grpc.netty
- ProtocolNegotiator.ServerFactory - Interface in io.grpc.netty
- ProtocolNegotiatorAdapter(ProtocolNegotiator) - Constructor for class io.grpc.netty.InternalProtocolNegotiator.ProtocolNegotiatorAdapter
- protocolNegotiatorFactory - Variable in class io.grpc.netty.NettyChannelBuilder
- protocolNegotiatorFactory - Variable in class io.grpc.netty.NettyServerBuilder
- protocolNegotiatorFactory(ProtocolNegotiator.ClientFactory) - Method in class io.grpc.netty.NettyChannelBuilder
- ProtocolNegotiators - Class in io.grpc.netty
-
Common
ProtocolNegotiator
s used by gRPC. - ProtocolNegotiators() - Constructor for class io.grpc.netty.ProtocolNegotiators
- ProtocolNegotiators.ClientTlsHandler - Class in io.grpc.netty
- ProtocolNegotiators.ClientTlsProtocolNegotiator - Class in io.grpc.netty
- ProtocolNegotiators.FixedProtocolNegotiatorServerFactory - Class in io.grpc.netty
- ProtocolNegotiators.FromChannelCredentialsResult - Class in io.grpc.netty
- ProtocolNegotiators.FromServerCredentialsResult - Class in io.grpc.netty
- ProtocolNegotiators.GrpcNegotiationHandler - Class in io.grpc.netty
-
Adapts a
ProtocolNegotiationEvent
to theGrpcHttp2ConnectionHandler
. - ProtocolNegotiators.HostPort - Class in io.grpc.netty
-
A tuple of (host, port).
- ProtocolNegotiators.Http2UpgradeAndGrpcHandler - Class in io.grpc.netty
-
Acts as a combination of Http2Upgrade and
ProtocolNegotiators.GrpcNegotiationHandler
. - ProtocolNegotiators.PlaintextProtocolNegotiator - Class in io.grpc.netty
-
A negotiator that only does plain text.
- ProtocolNegotiators.PlaintextProtocolNegotiatorClientFactory - Class in io.grpc.netty
- ProtocolNegotiators.PlaintextProtocolNegotiatorServerFactory - Class in io.grpc.netty
- ProtocolNegotiators.PlaintextUpgradeProtocolNegotiator - Class in io.grpc.netty
- ProtocolNegotiators.PlaintextUpgradeProtocolNegotiatorClientFactory - Class in io.grpc.netty
- ProtocolNegotiators.ProtocolNegotiationHandler - Class in io.grpc.netty
-
ProtocolNegotiationHandler is a convenience handler that makes it easy to follow the rules for protocol negotiation.
- ProtocolNegotiators.ProxyProtocolNegotiationHandler - Class in io.grpc.netty
-
A Proxy handler follows
ProtocolNegotiators.ProtocolNegotiationHandler
pattern. - ProtocolNegotiators.ServerTlsHandler - Class in io.grpc.netty
- ProtocolNegotiators.TlsProtocolNegotiatorClientFactory - Class in io.grpc.netty
- ProtocolNegotiators.TlsProtocolNegotiatorServerFactory - Class in io.grpc.netty
- ProtocolNegotiators.WaitUntilActiveHandler - Class in io.grpc.netty
-
Waits for the channel to be active, and then installs the next Handler.
- ProtoFileDescriptorSupplier - Interface in io.grpc.protobuf
-
Provides access to the underlying proto file descriptor.
- ProtoInputStream - Class in io.grpc.protobuf.lite
-
An
InputStream
backed by a protobuf. - ProtoInputStream(MessageLite, Parser<?>) - Constructor for class io.grpc.protobuf.lite.ProtoInputStream
- ProtoLiteUtils - Class in io.grpc.protobuf.lite
-
Utility methods for using protobuf with grpc.
- ProtoLiteUtils() - Constructor for class io.grpc.protobuf.lite.ProtoLiteUtils
- ProtoLiteUtils.MessageMarshaller<T> - Class in io.grpc.protobuf.lite
- ProtoLiteUtils.MetadataMarshaller<T> - Class in io.grpc.protobuf.lite
- ProtoMethodDescriptorSupplier - Interface in io.grpc.protobuf
-
Provides access to the underlying proto service method descriptor.
- ProtoReflectionService - Class in io.grpc.protobuf.services
-
Provides a reflection service for Protobuf services (including the reflection service itself).
- ProtoReflectionService() - Constructor for class io.grpc.protobuf.services.ProtoReflectionService
- ProtoReflectionServiceV1 - Class in io.grpc.protobuf.services
-
Provides a reflection service for Protobuf services (including the reflection service itself).
- ProtoReflectionServiceV1() - Constructor for class io.grpc.protobuf.services.ProtoReflectionServiceV1
- ProtoReflectionServiceV1.FileDescriptorIndex - Class in io.grpc.protobuf.services
-
Provides a set of methods for answering reflection queries for the file descriptors underlying a set of services.
- ProtoReflectionServiceV1.ProtoReflectionStreamObserver - Class in io.grpc.protobuf.services
- ProtoReflectionServiceV1.ServerReflectionIndex - Class in io.grpc.protobuf.services
-
Indexes the server's services and allows lookups of file descriptors by filename, symbol, type, and extension number.
- ProtoReflectionStreamObserver(ProtoReflectionServiceV1.ServerReflectionIndex, ServerCallStreamObserver<ServerReflectionResponse>) - Constructor for class io.grpc.protobuf.services.ProtoReflectionServiceV1.ProtoReflectionStreamObserver
- ProtoServiceDescriptorSupplier - Interface in io.grpc.protobuf
-
Provides access to the underlying proto service descriptor.
- ProtoUtils - Class in io.grpc.protobuf
-
Utility methods for using protobuf with grpc.
- ProtoUtils() - Constructor for class io.grpc.protobuf.ProtoUtils
- provider - Variable in class io.grpc.internal.ManagedChannelImplBuilder.ResolvedNameResolver
- provider - Variable in class io.grpc.internal.ServiceConfigUtil.PolicySelection
- provider() - Static method in class io.grpc.ManagedChannelProvider
-
Returns the ClassLoader-wide default channel.
- provider() - Method in class io.grpc.ManagedChannelRegistry
- provider() - Static method in class io.grpc.ServerProvider
-
Returns the ClassLoader-wide default server.
- provider() - Method in class io.grpc.ServerRegistry
- Provider() - Constructor for class io.grpc.grpclb.SecretGrpclbNameResolverProvider.Provider
- Provider() - Constructor for class io.grpc.internal.ExponentialBackoffPolicy.Provider
- Provider() - Constructor for class io.grpc.util.SecretRoundRobinLoadBalancerProvider.Provider
- PROVIDER - Static variable in class io.grpc.netty.GrpcSslContexts.ConscryptHolder
- ProviderNotFoundException(String) - Constructor for exception class io.grpc.ManagedChannelProvider.ProviderNotFoundException
- ProviderNotFoundException(String) - Constructor for exception class io.grpc.ManagedChannelRegistry.ProviderNotFoundException
- ProviderNotFoundException(String) - Constructor for exception class io.grpc.ServerRegistry.ProviderNotFoundException
- providers() - Method in class io.grpc.LoadBalancerRegistry
-
Returns effective providers in a new map.
- providers() - Method in class io.grpc.ManagedChannelRegistry
-
Returns effective providers, in priority order.
- providers() - Method in class io.grpc.NameResolverRegistry
-
Returns effective providers map from scheme to the highest priority NameResolverProvider of that scheme.
- providers() - Method in class io.grpc.ServerRegistry
-
Returns effective providers, in priority order.
- ProxiedSocketAddress - Class in io.grpc
-
An address that contains the information about making a connection via a proxy.
- ProxiedSocketAddress() - Constructor for class io.grpc.ProxiedSocketAddress
- PROXY_SCHEME - Static variable in class io.grpc.internal.ProxyDetectorImpl
- proxyAddress - Variable in class io.grpc.HttpConnectProxiedSocketAddress.Builder
- proxyAddress - Variable in class io.grpc.HttpConnectProxiedSocketAddress
- proxyDetector - Variable in class io.grpc.internal.DnsNameResolver
- proxyDetector - Variable in class io.grpc.internal.ManagedChannelImplBuilder
- proxyDetector - Variable in class io.grpc.NameResolver.Args.Builder
- proxyDetector - Variable in class io.grpc.NameResolver.Args
- proxyDetector(ProxyDetector) - Method in class io.grpc.ForwardingChannelBuilder
- proxyDetector(ProxyDetector) - Method in class io.grpc.ForwardingChannelBuilder2
- proxyDetector(ProxyDetector) - Method in class io.grpc.internal.ManagedChannelImplBuilder
- proxyDetector(ProxyDetector) - Method in class io.grpc.ManagedChannelBuilder
-
Sets the proxy detector to be used in addresses name resolution.
- ProxyDetector - Interface in io.grpc
-
A utility class to detect which proxy, if any, should be used for a given
SocketAddress
. - ProxyDetectorImpl - Class in io.grpc.internal
-
A utility class that detects proxies using
ProxySelector
and detects authentication credentials usingAuthenticator
. - ProxyDetectorImpl() - Constructor for class io.grpc.internal.ProxyDetectorImpl
-
A proxy selector that uses the global
ProxySelector.getDefault()
andProxyDetectorImpl.AuthenticationProvider
to detect proxy parameters. - ProxyDetectorImpl(Supplier<ProxySelector>, ProxyDetectorImpl.AuthenticationProvider, String) - Constructor for class io.grpc.internal.ProxyDetectorImpl
- ProxyDetectorImpl.AuthenticationProvider - Interface in io.grpc.internal
-
This interface makes unit testing easier by avoiding direct calls to static methods.
- proxyFor(SocketAddress) - Method in class io.grpc.internal.ProxyDetectorImpl
- proxyFor(SocketAddress) - Method in interface io.grpc.ProxyDetector
-
Given a target address, returns a proxied address if a proxy should be used.
- ProxyProtocolNegotiationHandler(SocketAddress, String, String, ChannelHandler, ChannelLogger) - Constructor for class io.grpc.netty.ProtocolNegotiators.ProxyProtocolNegotiationHandler
- proxySelector - Variable in class io.grpc.internal.ProxyDetectorImpl
- pushbackHedging(Integer) - Method in class io.grpc.internal.RetriableStream
- put(Metadata.Key<T>, T) - Method in class io.grpc.Metadata
-
Adds the
key, value
pair. - put(PersistentHashArrayMappedTrie.Node<K, V>, K, V) - Static method in class io.grpc.PersistentHashArrayMappedTrie
-
Returns a new trie where the key is set to the specified value.
- put(K, V, int, int) - Method in class io.grpc.PersistentHashArrayMappedTrie.CollisionLeaf
- put(K, V, int, int) - Method in class io.grpc.PersistentHashArrayMappedTrie.CompressedIndex
- put(K, V, int, int) - Method in class io.grpc.PersistentHashArrayMappedTrie.Leaf
- put(K, V, int, int) - Method in interface io.grpc.PersistentHashArrayMappedTrie.Node
- putAllConstantKeys(Map<String, String>) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
-
You can optionally set one or more specific key/value pairs to be added to the key_map.
- putAllConstantKeys(Map<String, String>) - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
-
You can optionally set one or more specific key/value pairs to be added to the key_map.
- putAllKeyMap(Map<String, String>) - Method in class io.grpc.lookup.v1.RouteLookupRequest.Builder
-
Map of key values extracted via key builders for the gRPC or HTTP request.
- putConstantKeys(String, String) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
-
You can optionally set one or more specific key/value pairs to be added to the key_map.
- putConstantKeys(String, String) - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
-
You can optionally set one or more specific key/value pairs to be added to the key_map.
- putKeyMap(String, String) - Method in class io.grpc.lookup.v1.RouteLookupRequest.Builder
-
Map of key values extracted via key builders for the gRPC or HTTP request.
- putNewTrackers(OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig, Set<Set<SocketAddress>>) - Method in class io.grpc.util.OutlierDetectionLoadBalancer.EndpointTrackerMap
-
Adds a new tracker for every given address.
- putUtilizationMetric(String, double) - Method in class io.grpc.services.MetricRecorder
-
Update the metrics value in the range [0, 1] corresponding to the specified key.
Q
- qps - Variable in class io.grpc.services.CallMetricRecorder
- qps - Variable in class io.grpc.services.MetricRecorder
- qps - Variable in class io.grpc.services.MetricReport
- QUERY_PARAMETERS_FIELD_NUMBER - Static variable in class io.grpc.lookup.v1.HttpKeyBuilder
- queryParameters_ - Variable in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
- queryParameters_ - Variable in class io.grpc.lookup.v1.HttpKeyBuilder
- queryParametersBuilder_ - Variable in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
- queue - Variable in class io.grpc.netty.WriteQueue
- queue - Variable in class io.grpc.SynchronizationContext
- QueuingListener() - Constructor for class io.grpc.stub.ClientCalls.BlockingResponseStream.QueuingListener
- QUIET_EXCEPTIONS - Static variable in class io.grpc.netty.NettyServerTransport
R
- random - Variable in class io.grpc.internal.DnsNameResolver
- random - Variable in class io.grpc.internal.ExponentialBackoffPolicy
- random - Static variable in class io.grpc.internal.RetriableStream
- randomFloat() - Static method in class io.grpc.rls.AdaptiveThrottler
- randomSeed - Variable in class io.grpc.internal.PickFirstLeafLoadBalancer.PickFirstLeafLoadBalancerConfig
- randomSeed - Variable in class io.grpc.internal.PickFirstLoadBalancer.PickFirstLoadBalancerConfig
- RATE_LIMITING - Enum constant in enum io.grpc.grpclb.DropType
- ratioForAccepts - Variable in class io.grpc.rls.AdaptiveThrottler.Builder
- ratioForAccepts - Variable in class io.grpc.rls.AdaptiveThrottler
-
The ratio by which the Adaptive Throttler will attempt to send requests above what the server is currently accepting.
- rawConfigValue - Variable in class io.grpc.internal.ServiceConfigUtil.LbConfig
- rawConnectivityState - Variable in class io.grpc.internal.PickFirstLeafLoadBalancer
- rawDeframer - Variable in class io.grpc.internal.AbstractStream.TransportState
- rawMethodNames - Variable in class io.grpc.MethodDescriptor
- rawState - Variable in class io.grpc.protobuf.services.HealthCheckingLoadBalancerFactory.HealthCheckState
- rcvMss - Variable in class io.grpc.InternalChannelz.TcpInfo.Builder
- rcvMss - Variable in class io.grpc.InternalChannelz.TcpInfo
- rcvSsthresh - Variable in class io.grpc.InternalChannelz.TcpInfo.Builder
- rcvSsthresh - Variable in class io.grpc.InternalChannelz.TcpInfo
- rcvWscale - Variable in class io.grpc.InternalChannelz.TcpInfo.Builder
- rcvWscale - Variable in class io.grpc.InternalChannelz.TcpInfo
- read() - Method in class io.grpc.internal.MessageDeframer.SizeEnforcingInputStream
- read() - Method in class io.grpc.internal.ReadableBuffers.BufferInputStream
- read() - Method in interface io.grpc.internal.TransportTracer.FlowControlReader
- read() - Method in class io.grpc.netty.Utils.FlowControlReader
- read() - Method in class io.grpc.protobuf.lite.ProtoInputStream
- read(byte[], int, int) - Method in class io.grpc.internal.MessageDeframer.SizeEnforcingInputStream
- read(byte[], int, int) - Method in class io.grpc.internal.ReadableBuffers.BufferInputStream
- read(byte[], int, int) - Method in class io.grpc.protobuf.lite.ProtoInputStream
- read(ReadableBuffer, int, T, int) - Method in interface io.grpc.internal.CompositeReadableBuffer.NoThrowReadOperation
- read(ReadableBuffer, int, T, int) - Method in interface io.grpc.internal.CompositeReadableBuffer.ReadOperation
-
This method can also be used to simultaneously perform operation-specific int-valued aggregation over the sequence of buffers in a
CompositeReadableBuffer
. - read(K) - Method in class io.grpc.rls.LinkedHashLruCache
- read(K) - Method in interface io.grpc.rls.LruCache
-
Returns cached value for given key if exists, otherwise
null
. - ReadableBuffer - Interface in io.grpc.internal
-
Interface for an abstract byte buffer.
- readableBuffers - Variable in class io.grpc.internal.CompositeReadableBuffer
- ReadableBuffers - Class in io.grpc.internal
-
Utility methods for creating
ReadableBuffer
instances. - ReadableBuffers() - Constructor for class io.grpc.internal.ReadableBuffers
- ReadableBuffers.BufferInputStream - Class in io.grpc.internal
-
An
InputStream
that is backed by aReadableBuffer
. - ReadableBuffers.ByteArrayWrapper - Class in io.grpc.internal
-
A
ReadableBuffer
that is backed by a byte array. - ReadableBuffers.ByteReadableBufferWrapper - Class in io.grpc.internal
-
A
ReadableBuffer
that is backed by aByteBuffer
. - readableBytes - Variable in class io.grpc.internal.CompositeReadableBuffer
- readableBytes() - Method in class io.grpc.internal.CompositeReadableBuffer
- readableBytes() - Method in class io.grpc.internal.ForwardingReadableBuffer
- readableBytes() - Method in class io.grpc.internal.GzipInflatingBuffer.GzipMetadataReader
- readableBytes() - Method in class io.grpc.internal.MessageFramer.BufferChainOutputStream
- readableBytes() - Method in interface io.grpc.internal.ReadableBuffer
-
Gets the current number of readable bytes remaining in this buffer.
- readableBytes() - Method in class io.grpc.internal.ReadableBuffers.ByteArrayWrapper
- readableBytes() - Method in class io.grpc.internal.ReadableBuffers.ByteReadableBufferWrapper
- readableBytes() - Method in interface io.grpc.internal.WritableBuffer
-
Returns the number of bytes one can read from the buffer.
- readableBytes() - Method in class io.grpc.netty.NettyReadableBuffer
- readableBytes() - Method in class io.grpc.netty.NettyWritableBuffer
- readableBytes() - Method in class io.grpc.servlet.jakarta.ServletServerStream.ByteArrayWritableBuffer
- readableBytes() - Method in class io.grpc.servlet.ServletServerStream.ByteArrayWritableBuffer
- readAndUpdate(File, long) - Method in class io.grpc.util.AdvancedTlsX509TrustManager
-
Reads the trust certificates specified in the path location, and updates the key store if the modified time has changed since last read.
- readAndUpdate(File, File, long, long) - Method in class io.grpc.util.AdvancedTlsX509KeyManager
-
Reads the private key and certificates specified in the path locations.
- readArray(ReadableBuffer) - Static method in class io.grpc.internal.ReadableBuffers
-
Reads an entire
ReadableBuffer
to a new array. - readAsString(ReadableBuffer, Charset) - Static method in class io.grpc.internal.ReadableBuffers
-
Reads the entire
ReadableBuffer
to a newString
with the given charset. - readAsStringUtf8(ReadableBuffer) - Static method in class io.grpc.internal.ReadableBuffers
-
Reads the entire
ReadableBuffer
to a newString
using UTF-8 decoding. - readBytes(byte[], int, int) - Method in class io.grpc.internal.CompositeReadableBuffer
- readBytes(byte[], int, 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(byte[], int, int) - Method in class io.grpc.internal.ReadableBuffers.ByteArrayWrapper
- readBytes(byte[], int, int) - Method in class io.grpc.internal.ReadableBuffers.ByteReadableBufferWrapper
- readBytes(byte[], int, int) - Method in class io.grpc.netty.NettyReadableBuffer
- readBytes(int) - Method in class io.grpc.internal.CompositeReadableBuffer
- readBytes(int) - Method in class io.grpc.internal.ForwardingReadableBuffer
- readBytes(int) - Method in interface io.grpc.internal.ReadableBuffer
-
Reads
length
bytes from this buffer and returns a new Buffer containing them. - readBytes(int) - Method in class io.grpc.internal.ReadableBuffers.ByteArrayWrapper
- readBytes(int) - Method in class io.grpc.internal.ReadableBuffers.ByteReadableBufferWrapper
- readBytes(int) - Method in class io.grpc.netty.NettyReadableBuffer
- readBytes(CompositeReadableBuffer, int) - Method in class io.grpc.internal.CompositeReadableBuffer
-
Reads
length
bytes from this buffer and writes them to the destination buffer. - readBytes(OutputStream, int) - Method in class io.grpc.internal.CompositeReadableBuffer
- readBytes(OutputStream, int) - Method in class io.grpc.internal.ForwardingReadableBuffer
- readBytes(OutputStream, int) - Method in interface io.grpc.internal.ReadableBuffer
-
Reads
length
bytes from this buffer and writes them to the destination stream. - readBytes(OutputStream, int) - Method in class io.grpc.internal.ReadableBuffers.ByteArrayWrapper
- readBytes(OutputStream, int) - Method in class io.grpc.internal.ReadableBuffers.ByteReadableBufferWrapper
- readBytes(OutputStream, int) - Method in class io.grpc.netty.NettyReadableBuffer
- readBytes(ByteBuffer) - Method in class io.grpc.internal.CompositeReadableBuffer
- readBytes(ByteBuffer) - Method in class io.grpc.internal.ForwardingReadableBuffer
- 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(ByteBuffer) - Method in class io.grpc.internal.ReadableBuffers.ByteArrayWrapper
- readBytes(ByteBuffer) - Method in class io.grpc.internal.ReadableBuffers.ByteReadableBufferWrapper
- readBytes(ByteBuffer) - Method in class io.grpc.netty.NettyReadableBuffer
- readBytesUntilZero() - Method in class io.grpc.internal.GzipInflatingBuffer.GzipMetadataReader
-
Skip over a zero-terminated byte sequence.
- 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.
- readInternal(K) - Method in class io.grpc.rls.LinkedHashLruCache
- ReadOnlyServerCall(ServerStreamTracer.ServerCallInfo<ReqT, RespT>) - Constructor for class io.grpc.ServerStreamTracer.ReadOnlyServerCall
-
Deprecated.
- readRequiredBytes() - Method in class io.grpc.internal.MessageDeframer
-
Attempts to read the required bytes into nextFrame.
- readTrustDomainsFromFile(String) - Static method in class io.grpc.internal.SpiffeUtil
- readUnsignedByte() - Method in class io.grpc.internal.CompositeReadableBuffer
- readUnsignedByte() - Method in class io.grpc.internal.ForwardingReadableBuffer
- readUnsignedByte() - Method in class io.grpc.internal.GzipInflatingBuffer.GzipMetadataReader
-
Returns the next unsigned byte, adding it the CRC and incrementing
bytesConsumed
. - readUnsignedByte() - Method in interface io.grpc.internal.ReadableBuffer
-
Reads the next unsigned byte from this buffer and increments the read position by 1.
- readUnsignedByte() - Method in class io.grpc.internal.ReadableBuffers.ByteArrayWrapper
- readUnsignedByte() - Method in class io.grpc.internal.ReadableBuffers.ByteReadableBufferWrapper
- readUnsignedByte() - Method in class io.grpc.netty.NettyReadableBuffer
- readUnsignedInt() - Method in class io.grpc.internal.GzipInflatingBuffer.GzipMetadataReader
-
Reads unsigned integer in Little-Endian byte order.
- readUnsignedShort() - Method in class io.grpc.internal.GzipInflatingBuffer.GzipMetadataReader
-
Reads unsigned short in Little-Endian byte order.
- READY - Enum constant in enum io.grpc.channelz.v1.ChannelConnectivityState.State
-
READY = 3;
- READY - Enum constant in enum io.grpc.ConnectivityState
-
The channel has successfully established a connection all the way through TLS handshake (or equivalent) and all subsequent attempt to communicate have succeeded (or are pending without any known failure ).
- READY_VALUE - Static variable in enum io.grpc.channelz.v1.ChannelConnectivityState.State
-
READY = 3;
- readyAndDrained - Variable in class io.grpc.servlet.AsyncServletOutputStreamWriter.WriteState
-
The servlet output stream is ready and the writeChain is empty.
- readyAndDrained - Variable in class io.grpc.servlet.jakarta.AsyncServletOutputStreamWriter.WriteState
-
The servlet output stream is ready and the writeChain is empty.
- ReadyPicker(List<LoadBalancer.SubchannelPicker>, AtomicInteger) - Constructor for class io.grpc.util.RoundRobinLoadBalancer.ReadyPicker
- realCall - Variable in class io.grpc.internal.DelayedClientCall
- realChannel - Variable in class io.grpc.internal.ManagedChannelImpl
- RealChannel(String) - Constructor for class io.grpc.internal.ManagedChannelImpl.RealChannel
- realListener - Variable in class io.grpc.internal.DelayedClientCall.DelayedListener
- realListener - Variable in class io.grpc.internal.DelayedStream.DelayedStreamListener
- realStream - Variable in class io.grpc.internal.DelayedStream
-
Must hold
this
lock when setting. - reason - Variable in class io.grpc.grpclb.GrpclbState.FallbackModeTask
- reason - Variable in class io.grpc.netty.CancelClientStreamCommand
- reason - Variable in class io.grpc.netty.CancelServerStreamCommand
- reason() - Method in class io.grpc.netty.CancelClientStreamCommand
- reason() - Method in class io.grpc.netty.CancelServerStreamCommand
- Reason(int) - Constructor for enum io.grpc.lookup.v1.RouteLookupRequest.Reason
- reason_ - Variable in class io.grpc.lookup.v1.RouteLookupRequest.Builder
- reason_ - Variable in class io.grpc.lookup.v1.RouteLookupRequest
- REASON_FIELD_NUMBER - Static variable in class io.grpc.lookup.v1.RouteLookupRequest
- REASON_MISS - Enum constant in enum io.grpc.lookup.v1.RouteLookupRequest.Reason
-
No data available in local cache
- REASON_MISS_VALUE - Static variable in enum io.grpc.lookup.v1.RouteLookupRequest.Reason
-
No data available in local cache
- REASON_STALE - Enum constant in enum io.grpc.lookup.v1.RouteLookupRequest.Reason
-
Data in local cache is stale
- REASON_STALE_VALUE - Static variable in enum io.grpc.lookup.v1.RouteLookupRequest.Reason
-
Data in local cache is stale
- REASON_UNKNOWN - Enum constant in enum io.grpc.lookup.v1.RouteLookupRequest.Reason
-
Unused
- REASON_UNKNOWN_VALUE - Static variable in enum io.grpc.lookup.v1.RouteLookupRequest.Reason
-
Unused
- reconnectDisabled - Variable in class io.grpc.internal.InternalSubchannel
- reconnectPolicy - Variable in class io.grpc.internal.InternalSubchannel
-
The policy to control back off between reconnects.
- reconnectPolicy - Variable in class io.grpc.internal.PickFirstLeafLoadBalancer
- reconnectTask - Variable in class io.grpc.internal.InternalSubchannel
- reconnectTask - Variable in class io.grpc.internal.PickFirstLeafLoadBalancer
- recordApplicationUtilizationMetric(double) - Method in class io.grpc.services.CallMetricRecorder
-
Records a call metric measurement for application specific utilization in the range [0, inf).
- recordCallMetric(String, double) - Method in class io.grpc.services.CallMetricRecorder
-
Deprecated.use
CallMetricRecorder.recordRequestCostMetric(java.lang.String, double)
instead. This method will be removed in the future. - recordCpuUtilizationMetric(double) - Method in class io.grpc.services.CallMetricRecorder
-
Records a call metric measurement for CPU utilization in the range [0, inf).
- recordDoubleHistogram(DoubleHistogramMetricInstrument, double, List<String>, List<String>) - Method in class io.grpc.internal.MetricRecorderImpl
-
Records a double histogram value.
- recordDoubleHistogram(DoubleHistogramMetricInstrument, double, List<String>, List<String>) - Method in interface io.grpc.MetricRecorder
-
Records a value for a double-precision histogram metric instrument.
- recordDoubleHistogram(DoubleHistogramMetricInstrument, double, List<String>, List<String>) - Method in interface io.grpc.MetricSink
-
Records a value for a double-precision histogram metric associated with specified metric instrument.
- recordDroppedRequest(String) - Method in class io.grpc.grpclb.GrpclbClientLoadRecorder
-
Records that a request has been dropped as instructed by the remote balancer.
- recordEpsMetric(double) - Method in class io.grpc.services.CallMetricRecorder
-
Records a call metric measurement for errors per second (eps) in the range [0, inf).
- recordFetcher - Variable in class io.grpc.internal.JndiResourceResolverFactory.JndiResourceResolver
- recordFinishedRpcs - Variable in class io.grpc.internal.ManagedChannelImplBuilder
- recordFinishedRpcs - Variable in class io.grpc.internal.ServerImplBuilder
- recordLongGauge(LongGaugeMetricInstrument, long, List<String>, List<String>) - Method in class io.grpc.internal.MetricRecorderImpl.BatchRecorderImpl
- recordLongGauge(LongGaugeMetricInstrument, long, List<String>, List<String>) - Method in interface io.grpc.MetricRecorder.BatchRecorder
-
Record a long gauge value.
- recordLongGauge(LongGaugeMetricInstrument, long, List<String>, List<String>) - Method in interface io.grpc.MetricSink
-
Record a long gauge value.
- recordLongHistogram(LongHistogramMetricInstrument, long, List<String>, List<String>) - Method in class io.grpc.internal.MetricRecorderImpl
-
Records a long histogram value.
- recordLongHistogram(LongHistogramMetricInstrument, long, List<String>, List<String>) - Method in interface io.grpc.MetricRecorder
-
Records a value for a long valued histogram metric instrument.
- recordLongHistogram(LongHistogramMetricInstrument, long, List<String>, List<String>) - Method in interface io.grpc.MetricSink
-
Records a value for a long valued histogram metric associated with specified metric instrument.
- recordMemoryUtilizationMetric(double) - Method in class io.grpc.services.CallMetricRecorder
-
Records a call metric measurement for memory utilization in the range [0, 1].
- recordNamedMetric(String, double) - Method in class io.grpc.services.CallMetricRecorder
-
Records an application-specific opaque custom metric measurement.
- recordQpsMetric(double) - Method in class io.grpc.services.CallMetricRecorder
-
Records a call metric measurement for queries per second (qps) in the range [0, inf).
- recordRealTimeMetrics - Variable in class io.grpc.internal.ManagedChannelImplBuilder
- recordRealTimeMetrics - Variable in class io.grpc.internal.ServerImplBuilder
- recordRequestCostMetric(String, double) - Method in class io.grpc.services.CallMetricRecorder
-
Records a call metric measurement for request cost.
- recordRetryMetrics - Variable in class io.grpc.internal.ManagedChannelImplBuilder
- recordStartedRpcs - Variable in class io.grpc.internal.ManagedChannelImplBuilder
- recordStartedRpcs - Variable in class io.grpc.internal.ServerImplBuilder
- recordUtilizationMetric(String, double) - Method in class io.grpc.services.CallMetricRecorder
-
Records a call metric measurement for utilization in the range [0, 1].
- recreateStates() - Method in class io.grpc.grpclb.GrpclbLoadBalancer
- recursionCount - Variable in class io.grpc.LoadBalancer
- recursionLimit - Variable in class io.grpc.protobuf.lite.ProtoLiteUtils.MessageMarshaller
- ref_ - Variable in class io.grpc.channelz.v1.Channel.Builder
- ref_ - Variable in class io.grpc.channelz.v1.Channel
- ref_ - Variable in class io.grpc.channelz.v1.Server.Builder
- ref_ - Variable in class io.grpc.channelz.v1.Server
- ref_ - Variable in class io.grpc.channelz.v1.Socket.Builder
- ref_ - Variable in class io.grpc.channelz.v1.Socket
- ref_ - Variable in class io.grpc.channelz.v1.Subchannel.Builder
- ref_ - Variable in class io.grpc.channelz.v1.Subchannel
- REF_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.Channel
- REF_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.Server
- REF_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.Socket
- REF_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.Subchannel
- refBuilder_ - Variable in class io.grpc.channelz.v1.Channel.Builder
- refBuilder_ - Variable in class io.grpc.channelz.v1.Server.Builder
- refBuilder_ - Variable in class io.grpc.channelz.v1.Socket.Builder
- refBuilder_ - Variable in class io.grpc.channelz.v1.Subchannel.Builder
- refCnt - Variable in class io.grpc.rls.LbPolicyConfiguration.RefCountedChildPolicyWrapper
- refcount - Variable in class io.grpc.internal.SharedResourceHolder.Instance
- RefCountedChildPolicyWrapper(LbPolicyConfiguration.ChildPolicyWrapper) - Constructor for class io.grpc.rls.LbPolicyConfiguration.RefCountedChildPolicyWrapper
- refCountedChildPolicyWrapperFactory - Variable in class io.grpc.rls.CachingRlsLbClient
- RefCountedChildPolicyWrapperFactory(LbPolicyConfiguration.ChildLoadBalancingPolicy, ResolvedAddressFactory, ChildLoadBalancerHelper.ChildLoadBalancerHelperProvider, LbPolicyConfiguration.ChildLbStatusListener) - Constructor for class io.grpc.rls.LbPolicyConfiguration.RefCountedChildPolicyWrapperFactory
- ReflectionLongAdderCounter - Class in io.grpc.internal
-
A
LongCounter
that is implemented with a JDK8invalid reference
LongAdder
- ReflectionLongAdderCounter() - Constructor for class io.grpc.internal.ReflectionLongAdderCounter
- refqueue - Variable in class io.grpc.internal.ManagedChannelOrphanWrapper.ManagedChannelReference
- refqueue - Static variable in class io.grpc.internal.ManagedChannelOrphanWrapper
- refresh() - Method in class io.grpc.internal.DnsNameResolver
- refresh() - Method in class io.grpc.internal.ForwardingNameResolver
- refresh() - Method in class io.grpc.NameResolver
-
Re-resolve the name.
- refresh() - Method in class io.grpc.netty.UdsNameResolver
- refreshBackoffEntry(CachingRlsLbClient.BackoffCacheEntry) - Method in class io.grpc.rls.CachingRlsLbClient
- refreshNameResolution() - Method in class io.grpc.internal.ManagedChannelImpl.LbHelperImpl
- refreshNameResolution() - Method in class io.grpc.internal.ManagedChannelImpl
-
Force name resolution refresh to happen immediately.
- refreshNameResolution() - Method in class io.grpc.LoadBalancer.Helper
-
Call
NameResolver.refresh()
on the channel's resolver. - refreshNameResolution() - Method in class io.grpc.util.ForwardingLoadBalancerHelper
- refreshProviderMap() - Method in class io.grpc.LoadBalancerRegistry
- refreshProviders() - Method in class io.grpc.ManagedChannelRegistry
- refreshProviders() - Method in class io.grpc.NameResolverRegistry
- refreshProviders() - Method in class io.grpc.ServerRegistry
- refreshState() - Method in class io.grpc.rls.LbPolicyConfiguration.ChildPolicyWrapper
- refs - Variable in class io.grpc.internal.ManagedChannelOrphanWrapper.ManagedChannelReference
- refs - Static variable in class io.grpc.internal.ManagedChannelOrphanWrapper
- REFUSED - Enum constant in enum io.grpc.internal.ClientStreamListener.RpcProgress
-
Some part of the RPC may have been sent, but the server has guaranteed it didn't process any part of the RPC.
- REFUSED_STREAM - Enum constant in enum io.grpc.internal.GrpcUtil.Http2Error
- register(Compressor) - Method in class io.grpc.CompressorRegistry
-
Registers a compressor for both decompression and message encoding negotiation.
- register(InProcessTransport) - Method in class io.grpc.inprocess.InProcessServer
- register(LoadBalancerProvider) - Method in class io.grpc.LoadBalancerRegistry
-
Register a provider.
- register(ManagedChannelProvider) - Method in class io.grpc.ManagedChannelRegistry
-
Register a provider.
- register(NameResolverProvider) - Method in class io.grpc.NameResolverRegistry
-
Register a provider.
- register(ServerProvider) - Method in class io.grpc.ServerRegistry
-
Register a provider.
- registerAllExtensions(ExtensionRegistry) - Static method in class io.grpc.binarylog.v1.BinaryLogProto
- registerAllExtensions(ExtensionRegistry) - Static method in class io.grpc.channelz.v1.ChannelzProto
- registerAllExtensions(ExtensionRegistry) - Static method in class io.grpc.health.v1.HealthProto
- registerAllExtensions(ExtensionRegistry) - Static method in class io.grpc.lb.v1.LoadBalancerProto
- registerAllExtensions(ExtensionRegistry) - Static method in class io.grpc.lookup.v1.RlsConfigProto
- registerAllExtensions(ExtensionRegistry) - Static method in class io.grpc.lookup.v1.RlsProto
- registerAllExtensions(ExtensionRegistry) - Static method in class io.grpc.reflection.v1.ServerReflectionProto
- registerAllExtensions(ExtensionRegistry) - Static method in class io.grpc.reflection.v1alpha.ServerReflectionProto
-
Deprecated.
- registerAllExtensions(ExtensionRegistryLite) - Static method in class io.grpc.binarylog.v1.BinaryLogProto
- registerAllExtensions(ExtensionRegistryLite) - Static method in class io.grpc.channelz.v1.ChannelzProto
- registerAllExtensions(ExtensionRegistryLite) - Static method in class io.grpc.health.v1.HealthProto
- registerAllExtensions(ExtensionRegistryLite) - Static method in class io.grpc.lb.v1.LoadBalancerProto
- registerAllExtensions(ExtensionRegistryLite) - Static method in class io.grpc.lookup.v1.RlsConfigProto
- registerAllExtensions(ExtensionRegistryLite) - Static method in class io.grpc.lookup.v1.RlsProto
- registerAllExtensions(ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1.ServerReflectionProto
- registerAllExtensions(ExtensionRegistryLite) - Static method in class io.grpc.reflection.v1alpha.ServerReflectionProto
-
Deprecated.
- registerBackendResponse(boolean) - Method in class io.grpc.rls.AdaptiveThrottler
- registerBackendResponse(boolean) - Method in class io.grpc.rls.CachingRlsLbClient.HappyThrottler
- registerBackendResponse(boolean) - Method in interface io.grpc.rls.Throttler
-
Registers a response received from the backend for a request allowed by shouldThrottle.
- registerBatchCallback(MetricRecorder.BatchCallback, CallbackMetricInstrument...) - Method in class io.grpc.internal.MetricRecorderImpl
- registerBatchCallback(MetricRecorder.BatchCallback, CallbackMetricInstrument...) - Method in interface io.grpc.MetricRecorder
-
Registers a callback to produce metric values for only the listed instruments.
- registerBatchCallback(Runnable, CallbackMetricInstrument...) - Method in interface io.grpc.MetricSink
-
Registers a callback to produce metric values for only the listed instruments.
- registerDoubleCounter(String, String, String, List<String>, List<String>, boolean) - Method in class io.grpc.MetricInstrumentRegistry
-
Registers a new Double Counter metric instrument.
- registerDoubleHistogram(String, String, String, List<Double>, List<String>, List<String>, boolean) - Method in class io.grpc.MetricInstrumentRegistry
-
Registers a new Double Histogram metric instrument.
- registeredMetricNames - Variable in class io.grpc.MetricInstrumentRegistry
- registerInstance() - Method in class io.grpc.inprocess.InProcessServer
- registerListener(SubchannelPool.PooledSubchannelStateListener) - Method in class io.grpc.grpclb.CachedSubchannelPool
- registerListener(SubchannelPool.PooledSubchannelStateListener) - Method in interface io.grpc.grpclb.SubchannelPool
-
Registers a listener to received Subchannel status updates.
- registerLongCounter(String, String, String, List<String>, List<String>, boolean) - Method in class io.grpc.MetricInstrumentRegistry
-
Registers a new Long Counter metric instrument.
- registerLongGauge(String, String, String, List<String>, List<String>, boolean) - Method in class io.grpc.MetricInstrumentRegistry
-
Registers a new Long Gauge metric instrument.
- registerLongHistogram(String, String, String, List<Long>, List<String>, List<String>, boolean) - Method in class io.grpc.MetricInstrumentRegistry
-
Registers a new Long Histogram metric instrument.
- registry - Static variable in class io.grpc.inprocess.InProcessServer
- registry - Variable in class io.grpc.internal.AutoConfiguredLoadBalancerFactory
- registry - Variable in class io.grpc.internal.MetricRecorderImpl
- registry - Variable in class io.grpc.internal.ServerImpl
- registryBuilder - Variable in class io.grpc.internal.ServerImplBuilder
- rejectRunnableOnExecutor - Static variable in class io.grpc.stub.ClientCalls
- release() - Method in class io.grpc.internal.ManagedChannelImpl.ExecutorHolder
- 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. - release() - Method in class io.grpc.netty.NettyWritableBuffer
- release() - Method in class io.grpc.servlet.jakarta.ServletServerStream.ByteArrayWritableBuffer
- release() - Method in class io.grpc.servlet.ServletServerStream.ByteArrayWritableBuffer
- release(SharedResourceHolder.Resource<T>, T) - Static method in class io.grpc.internal.SharedResourceHolder
-
Releases an instance of the given resource.
- release(LbPolicyConfiguration.ChildPolicyWrapper) - Method in class io.grpc.rls.LbPolicyConfiguration.RefCountedChildPolicyWrapperFactory
- releaseBuffer() - Method in class io.grpc.internal.MessageFramer
- releaseInternal(SharedResourceHolder.Resource<T>, T) - Method in class io.grpc.internal.SharedResourceHolder
-
Visible to unit tests.
- remainingNanos - Variable in class io.grpc.internal.ClientCallImpl.CancellationHandler
- remote - Variable in class io.grpc.InternalChannelz.SocketStats
- remote - Variable in class io.grpc.netty.Utils.FlowControlReader
- remote_ - Variable in class io.grpc.channelz.v1.Socket.Builder
- remote_ - Variable in class io.grpc.channelz.v1.Socket
- REMOTE_CERTIFICATE_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.Security.Tls
- REMOTE_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.Socket
- REMOTE_FLOW_CONTROL_WINDOW_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.SocketData
- REMOTE_NAME_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.Socket
- remoteAddress - Variable in class io.grpc.netty.NettyClientTransport
- remoteBuilder_ - Variable in class io.grpc.channelz.v1.Socket.Builder
- remoteBytes - Variable in class io.grpc.internal.TransportTracer.FlowControlWindows
- remoteCert - Variable in class io.grpc.InternalChannelz.Tls
- remoteCertificate_ - Variable in class io.grpc.channelz.v1.Security.Tls.Builder
- remoteCertificate_ - Variable in class io.grpc.channelz.v1.Security.Tls
- remoteFlowControlWindow - Variable in class io.grpc.InternalChannelz.TransportStats
- remoteFlowControlWindow_ - Variable in class io.grpc.channelz.v1.SocketData.Builder
- remoteFlowControlWindow_ - Variable in class io.grpc.channelz.v1.SocketData
- remoteFlowControlWindowBuilder_ - Variable in class io.grpc.channelz.v1.SocketData.Builder
- remoteName_ - Variable in class io.grpc.channelz.v1.Socket.Builder
- remoteName_ - Variable in class io.grpc.channelz.v1.Socket
- remove() - Method in class io.grpc.netty.GrpcHttp2OutboundHeaders.Itr
- remove() - Method in class io.grpc.stub.ClientCalls.BlockingResponseStream
- remove(RetriableStream<?>) - Method in class io.grpc.internal.ManagedChannelImpl.UncommittedRetriableStreamsRegistry
- remove(Metadata.Key<T>, T) - Method in class io.grpc.Metadata
-
Removes the first occurrence of
value
forkey
. - remove(CharSequence) - Method in class io.grpc.netty.AbstractHttp2Headers
- remove(CharSequence) - Method in class io.grpc.netty.GrpcHttp2HeadersUtils.GrpcHttp2InboundHeaders
- remove(CharSequence) - Method in class io.grpc.netty.GrpcHttp2HeadersUtils.GrpcHttp2RequestHeaders
- remove(Map<Long, T>, T) - Static method in class io.grpc.InternalChannelz
- removeActiveHedge(RetriableStream.Substream) - Method in class io.grpc.internal.RetriableStream.State
- removeAll(Metadata.Key<T>) - Method in class io.grpc.Metadata
-
Remove all values for the given key.
- removeCallsFinishedWithDrop(int) - Method in class io.grpc.lb.v1.ClientStats.Builder
-
The list of dropped calls.
- removeChannel(int) - Method in class io.grpc.channelz.v1.GetTopChannelsResponse.Builder
-
list of channels that the connection detail service knows about.
- removeChannelRef(int) - Method in class io.grpc.channelz.v1.Channel.Builder
-
There are no ordering guarantees on the order of channel refs.
- removeChannelRef(int) - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
There are no ordering guarantees on the order of channel refs.
- removeClientSocket(InternalInstrumented<InternalChannelz.SocketStats>) - Method in class io.grpc.InternalChannelz
- removeConstantKeys(String) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
-
You can optionally set one or more specific key/value pairs to be added to the key_map.
- removeConstantKeys(String) - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
-
You can optionally set one or more specific key/value pairs to be added to the key_map.
- removedChildren - Variable in class io.grpc.util.MultiChildLoadBalancer.AcceptResolvedAddrRetVal
- removeEntry(int) - Method in class io.grpc.binarylog.v1.Metadata.Builder
-
repeated .grpc.binarylog.v1.MetadataEntry entry = 1;
- removeEvents(int) - Method in class io.grpc.channelz.v1.ChannelTrace.Builder
-
List of events that have occurred on this channel.
- removeGrpcKeybuilders(int) - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
Unordered specifications for constructing keys for gRPC requests.
- removeHeaders(int) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
-
Extract keys from all listed headers.
- removeHeaders(int) - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
-
List of headers to try to match.
- removeHttpKeybuilders(int) - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
Ordered specifications for constructing keys for HTTP requests.
- removeKeyMap(String) - Method in class io.grpc.lookup.v1.RouteLookupRequest.Builder
-
Map of key values extracted via key builders for the gRPC or HTTP request.
- removeListener(Context.CancellationListener) - Method in class io.grpc.Context.CancellableContext
- removeListener(Context.CancellationListener) - Method in class io.grpc.Context
-
Remove a
Context.CancellationListener
. - removeListenerInternal(Context.CancellationListener, Context) - Method in class io.grpc.Context.CancellableContext
- removeListenSocket(int) - Method in class io.grpc.channelz.v1.Server.Builder
-
The sockets that the server is listening on.
- removeListenSocket(InternalInstrumented<InternalChannelz.SocketStats>) - Method in class io.grpc.InternalChannelz
- removeNames(int) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
-
repeated .grpc.lookup.v1.GrpcKeyBuilder.Name names = 1;
- removeOption(int) - Method in class io.grpc.channelz.v1.SocketData.Builder
-
Socket options set on this socket.
- removeQueryParameters(int) - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
-
List of query parameter names to try to match.
- removeRootChannel(InternalInstrumented<InternalChannelz.ChannelStats>) - Method in class io.grpc.InternalChannelz
- removeServer(int) - Method in class io.grpc.channelz.v1.GetServersResponse.Builder
-
list of servers that the connection detail service knows about.
- removeServer(InternalInstrumented<InternalChannelz.ServerStats>) - Method in class io.grpc.InternalChannelz
-
Removes a server.
- removeServers(int) - Method in class io.grpc.lb.v1.ServerList.Builder
-
Contains a list of servers selected by the load balancer.
- removeServerSocket(InternalInstrumented<InternalChannelz.ServerStats>, InternalInstrumented<InternalChannelz.SocketStats>) - Method in class io.grpc.InternalChannelz
-
Removes a server socket.
- removeService(int) - Method in class io.grpc.reflection.v1.ListServiceResponse.Builder
-
The information of each service may be expanded in the future, so we use ServiceResponse message to encapsulate it.
- removeService(int) - Method in class io.grpc.reflection.v1alpha.ListServiceResponse.Builder
-
The information of each service may be expanded in the future, so we use ServiceResponse message to encapsulate it.
- removeService(ServerServiceDefinition) - Method in class io.grpc.util.MutableHandlerRegistry
-
Removes a registered service.
- removeSocketRef(int) - Method in class io.grpc.channelz.v1.Channel.Builder
-
There are no ordering guarantees on the order of sockets.
- removeSocketRef(int) - Method in class io.grpc.channelz.v1.GetServerSocketsResponse.Builder
-
list of socket refs that the connection detail service knows about.
- removeSocketRef(int) - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
There are no ordering guarantees on the order of sockets.
- removeSubchannel(InternalInstrumented<InternalChannelz.ChannelStats>) - Method in class io.grpc.InternalChannelz
- removeSubchannel(OutlierDetectionLoadBalancer.OutlierDetectionSubchannel) - Method in class io.grpc.util.OutlierDetectionLoadBalancer.EndpointTracker
- removeSubchannelRef(int) - Method in class io.grpc.channelz.v1.Channel.Builder
-
At most one of 'channel_ref+subchannel_ref' and 'socket' is set.
- removeSubchannelRef(int) - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
At most one of 'channel_ref+subchannel_ref' and 'socket' is set.
- removeUtilizationMetric(String) - Method in class io.grpc.services.MetricRecorder
-
Remove the metrics data entry corresponding to the specified key.
- reordering - Variable in class io.grpc.InternalChannelz.TcpInfo.Builder
- reordering - Variable in class io.grpc.InternalChannelz.TcpInfo
- replace(ByteBuf) - Method in class io.grpc.netty.SendGrpcFrameCommand
- replaceActiveHedge(RetriableStream.Substream, RetriableStream.Substream) - Method in class io.grpc.internal.RetriableStream.State
- REPLACED - Enum constant in enum io.grpc.rls.LruCache.EvictionType
-
Evicted by replacement.
- replaceInappropriateControlPlaneStatus(Status) - Static method in class io.grpc.internal.GrpcUtil
-
Some status codes from the control plane are not appropritate to use in the data plane.
- replaceOnActive(ChannelHandlerContext) - Method in class io.grpc.netty.ProtocolNegotiators.WaitUntilActiveHandler
- replaceProtocolNegotiationEvent(ProtocolNegotiationEvent) - Method in class io.grpc.netty.ProtocolNegotiators.ProtocolNegotiationHandler
- reportCallEnded(boolean) - Method in class io.grpc.internal.CallTracer
- reportCallStarted() - Method in class io.grpc.internal.CallTracer
- reportCount() - Method in class io.grpc.internal.MessageDeframer.SizeEnforcingInputStream
- reportEvent(InternalChannelz.ChannelTrace.Event) - Method in class io.grpc.internal.ChannelTracer
- 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.
- reportTransportInUse - Variable in class io.grpc.internal.DelayedClientTransport
- reportTransportNotInUse - Variable in class io.grpc.internal.DelayedClientTransport
- reportTransportTerminated - Variable in class io.grpc.internal.DelayedClientTransport
- reprocess() - Method in class io.grpc.internal.ManagedChannelImpl.RealChannel.PendingCall
-
Called when it's ready to create a real call and reprocess the pending call.
- reprocess(LoadBalancer.SubchannelPicker) - Method in class io.grpc.internal.DelayedClientTransport
-
Use the picker to try picking a transport for every pending stream, proceed the stream if the pick is successful, otherwise keep it pending.
- request - Variable in class io.grpc.protobuf.services.ProtoReflectionServiceV1.ProtoReflectionStreamObserver
- request - Variable in class io.grpc.rls.CachingRlsLbClient.CacheEntry
- request - Variable in class io.grpc.rls.CachingRlsLbClient.PendingCacheEntry
- request - Variable in class io.grpc.stub.ServerCalls.UnaryServerCallHandler.UnaryServerCallListener
- request(int) - Method in class io.grpc.ClientCall
-
Requests up to the given number of messages from the call to be delivered to
ClientCall.Listener.onMessage(Object)
. - request(int) - Method in class io.grpc.inprocess.InProcessTransport.InProcessStream.InProcessClientStream
- request(int) - Method in class io.grpc.inprocess.InProcessTransport.InProcessStream.InProcessServerStream
- request(int) - Method in class io.grpc.internal.AbstractStream
- request(int) - Method in class io.grpc.internal.ApplicationThreadDeframer
- request(int) - Method in class io.grpc.internal.ClientCallImpl
- 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.DelayedClientCall
- request(int) - Method in class io.grpc.internal.DelayedStream
- request(int) - Method in class io.grpc.internal.ForwardingClientStream
- request(int) - Method in class io.grpc.internal.MessageDeframer
- request(int) - Method in class io.grpc.internal.MigratingThreadDeframer
- request(int) - Method in class io.grpc.internal.NoopClientStream
- request(int) - Method in class io.grpc.internal.RetriableStream
- request(int) - Method in class io.grpc.internal.ServerCallImpl
- request(int) - Method in interface io.grpc.internal.Stream
-
Requests up to the given number of messages from the call to be delivered via
StreamListener.messagesAvailable(StreamListener.MessageProducer)
. - request(int) - Method in interface io.grpc.internal.ThreadOptimizedDeframer
-
Behaves like
Deframer.request(int)
except it can be called from any thread. - request(int) - Method in class io.grpc.PartialForwardingClientCall
- request(int) - Method in class io.grpc.PartialForwardingServerCall
- request(int) - Method in class io.grpc.ServerCall
-
Requests up to the given number of messages from the call to be delivered to
ServerCall.Listener.onMessage(Object)
. - request(int) - Method in class io.grpc.stub.CallStreamObserver
-
Requests the peer to produce
count
more messages to be delivered to the 'inbound'StreamObserver
. - request(int) - Method in class io.grpc.stub.ClientCalls.CallToStreamObserverAdapter
- request(int) - Method in class io.grpc.stub.ClientCallStreamObserver
-
Requests the peer to produce
count
more messages to be delivered to the 'inbound'StreamObserver
. - request(int) - Method in class io.grpc.stub.ServerCalls.ServerCallStreamObserverImpl
- request(int) - Method in class io.grpc.stub.ServerCallStreamObserver
-
Requests the peer to produce
count
more messages to be delivered to the 'inbound'StreamObserver
. - request(int) - Method in class io.grpc.util.TransmitStatusRuntimeExceptionInterceptor.SerializingServerCall
- REQUEST_CONVERTER - Static variable in class io.grpc.rls.CachingRlsLbClient
- requestConnection() - Method in class io.grpc.grpclb.GrpclbLoadBalancer
- requestConnection() - Method in class io.grpc.grpclb.GrpclbState
- requestConnection() - Method in class io.grpc.internal.AutoConfiguredLoadBalancerFactory.AutoConfiguredLoadBalancer
- requestConnection() - Method in class io.grpc.internal.ManagedChannelImpl.SubchannelImpl
- requestConnection() - Method in class io.grpc.internal.PickFirstLeafLoadBalancer
-
Requests a connection to the next applicable address' subchannel, creating one if necessary.
- requestConnection() - Method in class io.grpc.internal.PickFirstLoadBalancer
- requestConnection() - Method in class io.grpc.LoadBalancer
-
The channel asks the LoadBalancer to establish connections now (if applicable) so that the upcoming RPC may then just pick a ready connection without waiting for connections.
- 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
-
Deprecated.override
LoadBalancer.requestConnection()
instead. - requestConnection() - Method in class io.grpc.rls.CachingRlsLbClient
- requestConnection() - Method in class io.grpc.rls.RlsLoadBalancer
- requestConnection() - Method in class io.grpc.util.ForwardingLoadBalancer
- requestConnection() - Method in class io.grpc.util.ForwardingSubchannel
- requestConnectionPending - Variable in class io.grpc.grpclb.GrpclbState
- RequestConnectionPicker(PickFirstLeafLoadBalancer) - Constructor for class io.grpc.internal.PickFirstLeafLoadBalancer.RequestConnectionPicker
- RequestConnectionPicker(LoadBalancer.Subchannel) - Constructor for class io.grpc.internal.PickFirstLoadBalancer.RequestConnectionPicker
- requestCostMetrics - Variable in class io.grpc.services.CallMetricRecorder
- requestCostMetrics - Variable in class io.grpc.services.MetricReport
- requestFactory - Variable in class io.grpc.rls.CachingRlsLbClient.RlsPicker
- requestFromTransportThread(int) - Method in class io.grpc.internal.MigratingThreadDeframer
- requestInfo - Variable in class io.grpc.CompositeCallCredentials.WrappingMetadataApplier
- RequestInfo() - Constructor for class io.grpc.CallCredentials.RequestInfo
- requestMarshaller - Variable in class io.grpc.MethodDescriptor.Builder
- requestMarshaller - Variable in class io.grpc.MethodDescriptor
- requestMessagesFromDeframer(int) - Method in class io.grpc.internal.AbstractStream.TransportState
-
Called to request the given number of messages from the deframer.
- requestMessagesFromDeframerForTesting(int) - Method in class io.grpc.internal.AbstractStream.TransportState
-
Very rarely used.
- requestObserver - Variable in class io.grpc.stub.ServerCalls.StreamingServerCallHandler.StreamingServerCallListener
- requestPasswordAuthentication(String, InetAddress, int, String, String, String) - Method in interface io.grpc.internal.ProxyDetectorImpl.AuthenticationProvider
- requestsPadding - Variable in class io.grpc.rls.AdaptiveThrottler.Builder
- requestsPadding - Variable in class io.grpc.rls.AdaptiveThrottler
-
A magic number to tune the aggressiveness of the throttling.
- requestStat - Variable in class io.grpc.rls.AdaptiveThrottler
-
The number of requests attempted by the client during the Adaptive Throttler instance's history of calls.
- requestType() - Element in annotation type io.grpc.stub.annotations.RpcMethod
-
The request type of the method.
- requestVolume - Variable in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig.FailurePercentageEjection.Builder
- requestVolume - Variable in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig.FailurePercentageEjection
- requestVolume - Variable in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig.SuccessRateEjection.Builder
- requestVolume - Variable in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig.SuccessRateEjection
- REQUIRE - Enum constant in enum io.grpc.TlsServerCredentials.ClientAuth
-
Clients are requested to present their identity, and are required to provide a valid identity.
- requireAsciiString(CharSequence) - Static method in class io.grpc.netty.GrpcHttp2HeadersUtils.GrpcHttp2InboundHeaders
- REQUIRED_MATCH_FIELD_NUMBER - Static variable in class io.grpc.lookup.v1.NameMatcher
- requiredFeature(Set<TlsChannelCredentials.Feature>, Set<TlsChannelCredentials.Feature>, TlsChannelCredentials.Feature) - Static method in class io.grpc.TlsChannelCredentials
- requiredFeature(Set<TlsServerCredentials.Feature>, Set<TlsServerCredentials.Feature>, TlsServerCredentials.Feature) - Static method in class io.grpc.TlsServerCredentials
- requiredLabelKeys - Variable in class io.grpc.PartialMetricInstrument
- requiredLength - Variable in class io.grpc.internal.MessageDeframer
- requiredMatch_ - Variable in class io.grpc.lookup.v1.NameMatcher.Builder
- requiredMatch_ - Variable in class io.grpc.lookup.v1.NameMatcher
- requireFakeFeature() - Method in class io.grpc.TlsChannelCredentials.Builder
-
Requires
TlsChannelCredentials.Feature.FAKE
to be understood. - requireFakeFeature() - Method in class io.grpc.TlsServerCredentials.Builder
-
Requires
TlsServerCredentials.Feature.FAKE
to be understood. - requireHttp2Stream(int) - Method in class io.grpc.netty.NettyClientHandler
- requireHttp2Stream(int) - Method in class io.grpc.netty.NettyServerHandler
- reschedule(long, TimeUnit) - Method in class io.grpc.internal.Rescheduler
- rescheduleIdleTimer() - Method in class io.grpc.internal.ManagedChannelImpl
- Rescheduler - Class in io.grpc.internal
-
Reschedules a runnable lazily.
- Rescheduler(Runnable, Executor, ScheduledExecutorService, Stopwatch) - Constructor for class io.grpc.internal.Rescheduler
- Rescheduler.ChannelFutureRunnable - Class in io.grpc.internal
- Rescheduler.FutureRunnable - Class in io.grpc.internal
- RESERVED_MASK - Static variable in class io.grpc.internal.MessageDeframer
- reset() - Method in class io.grpc.internal.AbstractReadableBuffer
- reset() - Method in class io.grpc.internal.BackoffPolicyRetryScheduler
-
Resets the
BackoffPolicyRetryScheduler
and cancels any pending retry task. - reset() - Method in class io.grpc.internal.CompositeReadableBuffer
- reset() - Method in class io.grpc.internal.ForwardingReadableBuffer
- reset() - Method in class io.grpc.internal.InternalSubchannel.Index
- reset() - Method in class io.grpc.internal.MessageDeframer.SizeEnforcingInputStream
- reset() - Method in class io.grpc.internal.PickFirstLeafLoadBalancer.Index
- reset() - Method in interface io.grpc.internal.ReadableBuffer
-
Repositions this buffer to the position at the time
ReadableBuffer.mark()
was last called on this buffer. - reset() - Method in class io.grpc.internal.ReadableBuffers.BufferInputStream
- reset() - Method in class io.grpc.internal.ReadableBuffers.ByteArrayWrapper
- reset() - Method in class io.grpc.internal.ReadableBuffers.ByteReadableBufferWrapper
- reset() - Method in interface io.grpc.internal.RetryScheduler
-
Resets the scheduler, effectively cancelling any future retry operation.
- reset() - Method in class io.grpc.netty.NettyReadableBuffer
- reset() - Method in class io.grpc.util.OutlierDetectionLoadBalancer.EndpointTracker.CallCounter
- RESET - Enum constant in enum io.grpc.netty.CancelServerStreamCommand.PeerNotify
-
Notify the peer by sending a RST_STREAM with no other information.
- resetCallCounters() - Method in class io.grpc.util.OutlierDetectionLoadBalancer.EndpointTracker
- resetCallCounters() - Method in class io.grpc.util.OutlierDetectionLoadBalancer.EndpointTrackerMap
-
Resets the call counters for all the trackers in the map.
- resetConnectBackoff() - Method in class io.grpc.internal.ForwardingManagedChannel
- resetConnectBackoff() - Method in class io.grpc.internal.InternalSubchannel
-
Immediately attempt to reconnect if the current state is TRANSIENT_FAILURE.
- resetConnectBackoff() - Method in class io.grpc.internal.ManagedChannelImpl
- resetConnectBackoff() - Method in class io.grpc.internal.OobChannel
- 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.
- resetCounters() - Method in class io.grpc.internal.KeepAliveEnforcer
-
Reset any counters because PINGs are allowed in response to something sent.
- resetEjectionTimeMultiplier() - Method in class io.grpc.util.OutlierDetectionLoadBalancer.EndpointTracker
- resetStates() - Method in class io.grpc.grpclb.GrpclbLoadBalancer
- resize(long) - Method in class io.grpc.rls.LinkedHashLruCache
-
Resizes cache.
- resizeMetricInstruments() - Method in class io.grpc.MetricInstrumentRegistry
- RESOLUTION_RESULT_LISTENER_KEY - Static variable in class io.grpc.internal.RetryingNameResolver
- resolutionAttempted(Status) - Method in class io.grpc.internal.RetryingNameResolver.ResolutionResultListener
- ResolutionResult(StatusOr<List<EquivalentAddressGroup>>, Attributes, NameResolver.ConfigOrError) - Constructor for class io.grpc.NameResolver.ResolutionResult
- ResolutionResultListener() - Constructor for class io.grpc.internal.RetryingNameResolver.ResolutionResultListener
- ResolutionState() - Constructor for enum io.grpc.internal.ManagedChannelImpl.ResolutionState
- resolve() - Method in class io.grpc.internal.DnsNameResolver
- resolve() - Method in class io.grpc.netty.UdsNameResolver
- Resolve(NameResolver.Listener2) - Constructor for class io.grpc.internal.DnsNameResolver.Resolve
- resolveAddress(String) - Method in interface io.grpc.internal.DnsNameResolver.AddressResolver
- resolveAddress(String) - Method in enum io.grpc.internal.DnsNameResolver.JdkAddressResolver
- resolveAddresses() - Method in class io.grpc.internal.DnsNameResolver
- resolveBalancerAddresses() - Method in class io.grpc.grpclb.GrpclbNameResolver
- resolved - Variable in class io.grpc.internal.DnsNameResolver
- resolvedAddresses - Variable in class io.grpc.util.MultiChildLoadBalancer.ChildLbState
- ResolvedAddresses(List<EquivalentAddressGroup>, Attributes, Object) - Constructor for class io.grpc.LoadBalancer.ResolvedAddresses
- resolvedAddressFactory - Variable in class io.grpc.rls.CachingRlsLbClient.Builder
- ResolvedAddressFactory - Interface in io.grpc.rls
-
A factory to create
LoadBalancer.ResolvedAddresses
. - ResolvedNameResolver(URI, NameResolverProvider) - Constructor for class io.grpc.internal.ManagedChannelImplBuilder.ResolvedNameResolver
- resolver - Variable in class io.grpc.internal.ManagedChannelImpl.NameResolverListener
- resolveServiceConfig() - Method in class io.grpc.internal.DnsNameResolver
- resolveSrv(String) - Method in interface io.grpc.internal.DnsNameResolver.ResourceResolver
- resolveSrv(String) - Method in class io.grpc.internal.JndiResourceResolverFactory.JndiResourceResolver
- resolveTxt(String) - Method in interface io.grpc.internal.DnsNameResolver.ResourceResolver
- resolveTxt(String) - Method in class io.grpc.internal.JndiResourceResolverFactory.JndiResourceResolver
- resolving - Variable in class io.grpc.internal.DnsNameResolver
- resolvingAddresses - Variable in class io.grpc.util.MultiChildLoadBalancer
- resource - Variable in class io.grpc.internal.SharedResourcePool
- RESOURCE_EXHAUSTED - Enum constant in enum io.grpc.Status.Code
-
Some resource has been exhausted, perhaps a per-user quota, or perhaps the entire file system is out of space.
- 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.
- resourceResolver - Variable in class io.grpc.internal.DnsNameResolver
- resourceResolverFactory - Static variable in class io.grpc.internal.DnsNameResolver
- resp - Variable in class io.grpc.servlet.jakarta.ServletServerStream
- resp - Variable in class io.grpc.servlet.ServletServerStream
- respondWithHttpError(ChannelHandlerContext, int, int, Status.Code, String) - Method in class io.grpc.netty.NettyServerHandler
- response - Variable in class io.grpc.rls.CachingRlsLbClient.DataCacheEntry
- RESPONSE_CONVERTER - Static variable in class io.grpc.rls.CachingRlsLbClient
- responseFuture - Variable in class io.grpc.stub.ClientCalls.UnaryStreamToFuture
- responseMarshaller - Variable in class io.grpc.MethodDescriptor.Builder
- responseMarshaller - Variable in class io.grpc.MethodDescriptor
- responseObserver - Variable in class io.grpc.stub.ServerCalls.StreamingServerCallHandler.StreamingServerCallListener
- responseObserver - Variable in class io.grpc.stub.ServerCalls.UnaryServerCallHandler.UnaryServerCallListener
- responseType() - Element in annotation type io.grpc.stub.annotations.RpcMethod
-
The response type of the method.
- RestrictedScheduledExecutor(ScheduledExecutorService) - Constructor for class io.grpc.internal.ManagedChannelImpl.RestrictedScheduledExecutor
- result - Variable in class io.grpc.grpclb.GrpclbState.BackendEntry
- result - Variable in class io.grpc.grpclb.GrpclbState.ErrorEntry
- result - Variable in class io.grpc.internal.PickFirstLeafLoadBalancer.Picker
- result - Variable in class io.grpc.internal.PickFirstLoadBalancer.Picker
- result - Variable in class io.grpc.LoadBalancer.FixedResultPicker
- Result(Status, Object, ClientInterceptor) - Constructor for class io.grpc.InternalConfigSelector.Result
- ResultCountingClientStreamTracerFactory(OutlierDetectionLoadBalancer.EndpointTracker, ClientStreamTracer.Factory) - Constructor for class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionPicker.ResultCountingClientStreamTracerFactory
- retrans - Variable in class io.grpc.InternalChannelz.TcpInfo.Builder
- retrans - Variable in class io.grpc.InternalChannelz.TcpInfo
- retransmits - Variable in class io.grpc.InternalChannelz.TcpInfo.Builder
- retransmits - Variable in class io.grpc.InternalChannelz.TcpInfo
- RetriableStream<ReqT> - Class in io.grpc.internal
-
A logical
ClientStream
that is retriable. - RetriableStream(MethodDescriptor<ReqT, ?>, Metadata, RetriableStream.ChannelBufferMeter, long, long, Executor, ScheduledExecutorService, RetryPolicy, HedgingPolicy, RetriableStream.Throttle) - Constructor for class io.grpc.internal.RetriableStream
- RetriableStream.BufferEntry - Interface in io.grpc.internal
- RetriableStream.BufferSizeTracer - Class in io.grpc.internal
-
Traces the buffer used by a substream.
- RetriableStream.ChannelBufferMeter - Class in io.grpc.internal
-
Used to keep track of the total amount of memory used to buffer retryable or hedged RPCs for the Channel.
- RetriableStream.FutureCanceller - Class in io.grpc.internal
-
Allows cancelling a Future without racing with setting the future.
- RetriableStream.HedgingPlan - Class in io.grpc.internal
- RetriableStream.HedgingRunnable - Class in io.grpc.internal
- RetriableStream.RetryPlan - Class in io.grpc.internal
- RetriableStream.SavedCloseMasterListenerReason - Class in io.grpc.internal
- RetriableStream.StartEntry - Class in io.grpc.internal
- RetriableStream.State - Class in io.grpc.internal
- RetriableStream.Sublistener - Class in io.grpc.internal
- RetriableStream.Substream - Class in io.grpc.internal
-
A wrapper of a physical stream of a retry/hedging attempt, that comes with some useful attributes.
- RetriableStream.Throttle - Class in io.grpc.internal
-
Used for retry throttling.
- retriedNameResolver - Variable in class io.grpc.internal.RetryingNameResolver
- retryableStatusCodes - Variable in class io.grpc.internal.RetryPolicy
- retryBufferSize - Variable in class io.grpc.internal.ManagedChannelImplBuilder
- retryBufferSize(long) - Method in class io.grpc.ForwardingChannelBuilder
- retryBufferSize(long) - Method in class io.grpc.ForwardingChannelBuilder2
- retryBufferSize(long) - Method in class io.grpc.internal.ManagedChannelImplBuilder
- retryBufferSize(long) - Method in class io.grpc.ManagedChannelBuilder
-
Sets the retry buffer size in bytes.
- retryEnabled - Variable in class io.grpc.internal.ManagedChannelImpl
- retryEnabled - Variable in class io.grpc.internal.ManagedChannelImplBuilder
- retryEnabled - Variable in class io.grpc.internal.ScParser
- RetryingListener(NameResolver.Listener2) - Constructor for class io.grpc.internal.RetryingNameResolver.RetryingListener
- RetryingNameResolver - Class in io.grpc.internal
-
This wrapper class can add retry capability to any polling
NameResolver
implementation that supports callingRetryingNameResolver.ResolutionResultListener
s with the outcome of each resolution. - RetryingNameResolver(NameResolver, RetryScheduler, SynchronizationContext) - Constructor for class io.grpc.internal.RetryingNameResolver
-
Creates a new
RetryingNameResolver
. - RetryingNameResolver.DelayedNameResolverRefresh - Class in io.grpc.internal
- RetryingNameResolver.ResolutionResultListener - Class in io.grpc.internal
-
Simple callback class to store in
NameResolver.ResolutionResult
attributes so that ManagedChannel can indicate if the resolved addresses were accepted. - RetryingNameResolver.RetryingListener - Class in io.grpc.internal
- RetryPlan(boolean, long) - Constructor for class io.grpc.internal.RetriableStream.RetryPlan
- retryPolicy - Variable in class io.grpc.internal.ManagedChannelServiceConfig.MethodInfo
- retryPolicy - Variable in class io.grpc.internal.RetriableStream
- retryPolicy(Map<String, ?>, int) - Static method in class io.grpc.internal.ManagedChannelServiceConfig.MethodInfo
- RetryPolicy - Class in io.grpc.internal
-
Retry policy data object.
- RetryPolicy(int, long, long, double, Long, Set<Status.Code>) - Constructor for class io.grpc.internal.RetryPolicy
-
The caller is supposed to have validated the arguments and handled throwing exception or logging warnings already, so we avoid repeating args check here.
- retryScheduler - Variable in class io.grpc.internal.RetryingNameResolver
- RetryScheduler - Interface in io.grpc.internal
-
This interface is used to schedule future retry attempts for a failed operation.
- retryTask - Variable in class io.grpc.protobuf.services.HealthCheckingLoadBalancerFactory.HealthCheckState
- retryThrottling - Variable in class io.grpc.internal.ManagedChannelServiceConfig
- retryTimer - Variable in class io.grpc.protobuf.services.HealthCheckingLoadBalancerFactory.HealthCheckState
- returnedStream - Variable in class io.grpc.internal.MetadataApplierImpl
- 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
- returnObject(Object) - Method in class io.grpc.rls.LbPolicyConfiguration.RefCountedChildPolicyWrapper
- returnProcessedBytes(Http2Stream, int) - Method in class io.grpc.netty.NettyClientHandler
-
Returns the given processed bytes back to inbound flow control.
- returnProcessedBytes(Http2Stream, int) - Method in class io.grpc.netty.NettyServerHandler
-
Returns the given processed bytes back to inbound flow control.
- returnStream() - Method in class io.grpc.internal.MetadataApplierImpl
-
Return a stream on which the RPC will run on.
- returnSubchannel(LoadBalancer.Subchannel, ConnectivityStateInfo) - Method in class io.grpc.grpclb.CachedSubchannelPool
- returnSubchannel(LoadBalancer.Subchannel, ConnectivityStateInfo) - Method in interface io.grpc.grpclb.SubchannelPool
-
Puts a
LoadBalancer.Subchannel
back to the pool. - returnSubchannelToPool(LoadBalancer.Subchannel) - Method in class io.grpc.grpclb.GrpclbState
- rewindableBuffers - Variable in class io.grpc.internal.CompositeReadableBuffer
- RLS_DATA_KEY - Static variable in class io.grpc.rls.CachingRlsLbClient
-
A header will be added when RLS server respond with additional header data.
- RlsAsyncLruCache(long, LruCache.EvictionListener<RlsProtoData.RouteLookupRequest, CachingRlsLbClient.CacheEntry>, Ticker, CachingRlsLbClient.RlsLbHelper) - Constructor for class io.grpc.rls.CachingRlsLbClient.RlsAsyncLruCache
- rlsChannel - Variable in class io.grpc.rls.CachingRlsLbClient
- RlsConfigProto - Class in io.grpc.lookup.v1
- RlsConfigProto() - Constructor for class io.grpc.lookup.v1.RlsConfigProto
- rlsHelper - Variable in class io.grpc.rls.ChildLoadBalancerHelper
- RlsLbHelper(LoadBalancer.Helper) - Constructor for class io.grpc.rls.CachingRlsLbClient.RlsLbHelper
- RlsLoadBalancer - Class in io.grpc.rls
-
Implementation of
LoadBalancer
backed by route lookup service. - RlsLoadBalancer(LoadBalancer.Helper) - Constructor for class io.grpc.rls.RlsLoadBalancer
- RlsLoadBalancer.CachingRlsLbClientBuilderProvider - Interface in io.grpc.rls
-
Provides
CachingRlsLbClient.Builder
with default settings. - RlsLoadBalancer.DefaultCachingRlsLbClientBuilderProvider - Class in io.grpc.rls
- RlsLoadBalancerProvider - Class in io.grpc.rls
-
The provider for the "rls_experimental" balancing policy.
- RlsLoadBalancerProvider() - Constructor for class io.grpc.rls.RlsLoadBalancerProvider
- rlsPicker - Variable in class io.grpc.rls.CachingRlsLbClient
- RlsPicker(RlsRequestFactory, String) - Constructor for class io.grpc.rls.CachingRlsLbClient.RlsPicker
- RlsProto - Class in io.grpc.lookup.v1
- RlsProto() - Constructor for class io.grpc.lookup.v1.RlsProto
- RlsProtoConverters - Class in io.grpc.rls
-
RlsProtoConverters is a collection of
Converter
between RouteLookupService proto / json messages to internal representation inRlsProtoData
. - RlsProtoConverters() - Constructor for class io.grpc.rls.RlsProtoConverters
- RlsProtoConverters.GrpcKeyBuilderConverter - Class in io.grpc.rls
- RlsProtoConverters.RouteLookupConfigConverter - Class in io.grpc.rls
-
RouteLookupConfigConverter converts between json map to
RlsProtoData.RouteLookupConfig
. - RlsProtoConverters.RouteLookupRequestConverter - Class in io.grpc.rls
-
RouteLookupRequestConverter converts between
RouteLookupRequest
andRlsProtoData.RouteLookupRequest
. - RlsProtoConverters.RouteLookupResponseConverter - Class in io.grpc.rls
-
RouteLookupResponseConverter converts between
RouteLookupResponse
andRlsProtoData.RouteLookupResponse
. - RlsProtoData - Class in io.grpc.rls
-
RlsProtoData is a collection of internal representation of RouteLookupService proto messages.
- RlsProtoData() - Constructor for class io.grpc.rls.RlsProtoData
- RlsProtoData.ExtraKeys - Class in io.grpc.rls
- RlsProtoData.GrpcKeyBuilder - Class in io.grpc.rls
-
GrpcKeyBuilder is a configuration to construct headers consumed by route lookup service.
- RlsProtoData.GrpcKeyBuilder.Name - Class in io.grpc.rls
-
Name represents a method for a given service.
- RlsProtoData.NameMatcher - Class in io.grpc.rls
-
NameMatcher extract a key based on a given name (e.g.
- RlsProtoData.RouteLookupConfig - Class in io.grpc.rls
-
A config object for gRPC RouteLookupService.
- RlsProtoData.RouteLookupConfig.Builder - Class in io.grpc.rls
- RlsProtoData.RouteLookupRequest - Class in io.grpc.rls
-
A request object sent to route lookup service.
- RlsProtoData.RouteLookupResponse - Class in io.grpc.rls
-
A response from route lookup service.
- RlsRequestFactory - Class in io.grpc.rls
-
A RlsRequestFactory creates
RlsProtoData.RouteLookupRequest
using key builder map fromRlsProtoData.RouteLookupConfig
. - RlsRequestFactory(RlsProtoData.RouteLookupConfig, String) - Constructor for class io.grpc.rls.RlsRequestFactory
- rlsStub - Variable in class io.grpc.rls.CachingRlsLbClient
- ROOT - Static variable in class io.grpc.Context
-
The logical root context which is the ultimate ancestor of all contexts.
- rootCertificates - Variable in class io.grpc.TlsChannelCredentials.Builder
- rootCertificates - Variable in class io.grpc.TlsChannelCredentials
- rootCertificates - Variable in class io.grpc.TlsServerCredentials.Builder
- rootCertificates - Variable in class io.grpc.TlsServerCredentials
- RootChannelList(List<InternalInstrumented<InternalChannelz.ChannelStats>>, boolean) - Constructor for class io.grpc.InternalChannelz.RootChannelList
-
Creates an instance.
- rootChannels - Variable in class io.grpc.InternalChannelz
- rootContext - Variable in class io.grpc.internal.ServerImpl
- ROUND_ROBIN - Enum constant in enum io.grpc.grpclb.GrpclbState.Mode
- RoundRobinLoadBalancer - Class in io.grpc.util
-
A
LoadBalancer
that provides round-robin load-balancing over theEquivalentAddressGroup
s from theNameResolver
. - RoundRobinLoadBalancer(LoadBalancer.Helper) - Constructor for class io.grpc.util.RoundRobinLoadBalancer
- RoundRobinLoadBalancer.ReadyPicker - Class in io.grpc.util
- RoundRobinPicker(List<GrpclbState.DropEntry>, List<? extends GrpclbState.RoundRobinEntry>) - Constructor for class io.grpc.grpclb.GrpclbState.RoundRobinPicker
- roundTripTimeNanos - Variable in class io.grpc.internal.Http2Ping
-
The round-trip time for the ping, in nanoseconds.
- ROUTE_LOOKUP_CONFIG_FIELD_NUMBER - Static variable in class io.grpc.lookup.v1.RouteLookupClusterSpecifier
- routeLookup(RouteLookupRequest) - Method in class io.grpc.lookup.v1.RouteLookupServiceGrpc.RouteLookupServiceBlockingStub
-
Lookup returns a target for a single key.
- routeLookup(RouteLookupRequest) - Method in class io.grpc.lookup.v1.RouteLookupServiceGrpc.RouteLookupServiceFutureStub
-
Lookup returns a target for a single key.
- routeLookup(RouteLookupRequest, StreamObserver<RouteLookupResponse>) - Method in interface io.grpc.lookup.v1.RouteLookupServiceGrpc.AsyncService
-
Lookup returns a target for a single key.
- routeLookup(RouteLookupRequest, StreamObserver<RouteLookupResponse>) - Method in class io.grpc.lookup.v1.RouteLookupServiceGrpc.RouteLookupServiceStub
-
Lookup returns a target for a single key.
- routeLookupChannelServiceConfig - Variable in class io.grpc.rls.LbPolicyConfiguration
- routeLookupClient - Variable in class io.grpc.rls.RlsLoadBalancer
- RouteLookupClusterSpecifier - Class in io.grpc.lookup.v1
-
RouteLookupClusterSpecifier is used in xDS to represent a cluster specifier plugin for RLS.
- RouteLookupClusterSpecifier() - Constructor for class io.grpc.lookup.v1.RouteLookupClusterSpecifier
- RouteLookupClusterSpecifier(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.lookup.v1.RouteLookupClusterSpecifier
- RouteLookupClusterSpecifier.Builder - Class in io.grpc.lookup.v1
-
RouteLookupClusterSpecifier is used in xDS to represent a cluster specifier plugin for RLS.
- RouteLookupClusterSpecifierOrBuilder - Interface in io.grpc.lookup.v1
- routeLookupConfig - Variable in class io.grpc.rls.LbPolicyConfiguration
- RouteLookupConfig - Class in io.grpc.lookup.v1
-
Protobuf type
grpc.lookup.v1.RouteLookupConfig
- RouteLookupConfig() - Constructor for class io.grpc.lookup.v1.RouteLookupConfig
- RouteLookupConfig() - Constructor for class io.grpc.rls.RlsProtoData.RouteLookupConfig
- RouteLookupConfig(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.lookup.v1.RouteLookupConfig
- routeLookupConfig_ - Variable in class io.grpc.lookup.v1.RouteLookupClusterSpecifier.Builder
- routeLookupConfig_ - Variable in class io.grpc.lookup.v1.RouteLookupClusterSpecifier
- RouteLookupConfig.Builder - Class in io.grpc.lookup.v1
-
Protobuf type
grpc.lookup.v1.RouteLookupConfig
- routeLookupConfigBuilder_ - Variable in class io.grpc.lookup.v1.RouteLookupClusterSpecifier.Builder
- RouteLookupConfigConverter() - Constructor for class io.grpc.rls.RlsProtoConverters.RouteLookupConfigConverter
- RouteLookupConfigOrBuilder - Interface in io.grpc.lookup.v1
- RouteLookupRequest - Class in io.grpc.lookup.v1
-
Protobuf type
grpc.lookup.v1.RouteLookupRequest
- RouteLookupRequest() - Constructor for class io.grpc.lookup.v1.RouteLookupRequest
- RouteLookupRequest() - Constructor for class io.grpc.rls.RlsProtoData.RouteLookupRequest
- RouteLookupRequest(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.lookup.v1.RouteLookupRequest
- RouteLookupRequest.Builder - Class in io.grpc.lookup.v1
-
Protobuf type
grpc.lookup.v1.RouteLookupRequest
- RouteLookupRequest.KeyMapDefaultEntryHolder - Class in io.grpc.lookup.v1
- RouteLookupRequest.Reason - Enum in io.grpc.lookup.v1
-
Possible reasons for making a request.
- RouteLookupRequestConverter() - Constructor for class io.grpc.rls.RlsProtoConverters.RouteLookupRequestConverter
- RouteLookupRequestOrBuilder - Interface in io.grpc.lookup.v1
- RouteLookupResponse - Class in io.grpc.lookup.v1
-
Protobuf type
grpc.lookup.v1.RouteLookupResponse
- RouteLookupResponse() - Constructor for class io.grpc.lookup.v1.RouteLookupResponse
- RouteLookupResponse() - Constructor for class io.grpc.rls.RlsProtoData.RouteLookupResponse
- RouteLookupResponse(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.lookup.v1.RouteLookupResponse
- RouteLookupResponse.Builder - Class in io.grpc.lookup.v1
-
Protobuf type
grpc.lookup.v1.RouteLookupResponse
- RouteLookupResponseConverter() - Constructor for class io.grpc.rls.RlsProtoConverters.RouteLookupResponseConverter
- RouteLookupResponseOrBuilder - Interface in io.grpc.lookup.v1
- RouteLookupServiceBaseDescriptorSupplier() - Constructor for class io.grpc.lookup.v1.RouteLookupServiceGrpc.RouteLookupServiceBaseDescriptorSupplier
- RouteLookupServiceBlockingStub(Channel, CallOptions) - Constructor for class io.grpc.lookup.v1.RouteLookupServiceGrpc.RouteLookupServiceBlockingStub
- RouteLookupServiceFileDescriptorSupplier() - Constructor for class io.grpc.lookup.v1.RouteLookupServiceGrpc.RouteLookupServiceFileDescriptorSupplier
- RouteLookupServiceFutureStub(Channel, CallOptions) - Constructor for class io.grpc.lookup.v1.RouteLookupServiceGrpc.RouteLookupServiceFutureStub
- RouteLookupServiceGrpc - Class in io.grpc.lookup.v1
- RouteLookupServiceGrpc() - Constructor for class io.grpc.lookup.v1.RouteLookupServiceGrpc
- RouteLookupServiceGrpc.AsyncService - Interface in io.grpc.lookup.v1
- RouteLookupServiceGrpc.MethodHandlers<Req,
Resp> - Class in io.grpc.lookup.v1 - RouteLookupServiceGrpc.RouteLookupServiceBaseDescriptorSupplier - Class in io.grpc.lookup.v1
- RouteLookupServiceGrpc.RouteLookupServiceBlockingStub - Class in io.grpc.lookup.v1
-
A stub to allow clients to do synchronous rpc calls to service RouteLookupService.
- RouteLookupServiceGrpc.RouteLookupServiceFileDescriptorSupplier - Class in io.grpc.lookup.v1
- RouteLookupServiceGrpc.RouteLookupServiceFutureStub - Class in io.grpc.lookup.v1
-
A stub to allow clients to do ListenableFuture-style rpc calls to service RouteLookupService.
- RouteLookupServiceGrpc.RouteLookupServiceImplBase - Class in io.grpc.lookup.v1
-
Base class for the server implementation of the service RouteLookupService.
- RouteLookupServiceGrpc.RouteLookupServiceMethodDescriptorSupplier - Class in io.grpc.lookup.v1
- RouteLookupServiceGrpc.RouteLookupServiceStub - Class in io.grpc.lookup.v1
-
A stub to allow clients to do asynchronous rpc calls to service RouteLookupService.
- RouteLookupServiceImplBase() - Constructor for class io.grpc.lookup.v1.RouteLookupServiceGrpc.RouteLookupServiceImplBase
- RouteLookupServiceMethodDescriptorSupplier(String) - Constructor for class io.grpc.lookup.v1.RouteLookupServiceGrpc.RouteLookupServiceMethodDescriptorSupplier
- RouteLookupServiceStub(Channel, CallOptions) - Constructor for class io.grpc.lookup.v1.RouteLookupServiceGrpc.RouteLookupServiceStub
- RpcMethod - Annotation Type in io.grpc.stub.annotations
-
RpcMethod
contains a limited subset of information about the RPC to assist Java Annotation Processors. - rpcProgress - Variable in class io.grpc.internal.FailingClientStream
- rpcProgress - Variable in class io.grpc.internal.FailingClientTransport
- RpcProgress() - Constructor for enum io.grpc.internal.ClientStreamListener.RpcProgress
- rrProvider - Variable in class io.grpc.protobuf.services.internal.HealthCheckingRoundRobinLoadBalancerProvider
- rstCount - Variable in class io.grpc.netty.NettyServerHandler
- rto - Variable in class io.grpc.InternalChannelz.TcpInfo.Builder
- rto - Variable in class io.grpc.InternalChannelz.TcpInfo
- rtt - Variable in class io.grpc.InternalChannelz.TcpInfo.Builder
- rtt - Variable in class io.grpc.InternalChannelz.TcpInfo
- rttvar - Variable in class io.grpc.InternalChannelz.TcpInfo.Builder
- rttvar - Variable in class io.grpc.InternalChannelz.TcpInfo
- run() - Method in class io.grpc.Context.ExecutableListener
- run() - Method in class io.grpc.grpclb.CachedSubchannelPool.ShutdownSubchannelTask
- run() - Method in class io.grpc.grpclb.GrpclbState.FallbackModeTask
- run() - Method in class io.grpc.grpclb.GrpclbState.LbRpcRetryTask
- run() - Method in class io.grpc.grpclb.GrpclbState.LoadReportingTask
- run() - Method in class io.grpc.internal.ClientCallImpl.CancellationHandler
- run() - Method in class io.grpc.internal.ContextRunnable
- run() - Method in class io.grpc.internal.DnsNameResolver.Resolve
- run() - Method in class io.grpc.internal.LogExceptionRunnable
- run() - Method in class io.grpc.internal.ManagedChannelImpl.IdleModeTimer
- run() - Method in class io.grpc.internal.ManagedChannelImpl.RealChannel.PendingCall.PendingCallRemoval
- run() - Method in class io.grpc.internal.Rescheduler.ChannelFutureRunnable
- run() - Method in class io.grpc.internal.Rescheduler.FutureRunnable
- run() - Method in class io.grpc.internal.RetriableStream.HedgingRunnable
- run() - Method in class io.grpc.internal.RetryingNameResolver.DelayedNameResolverRefresh
- run() - Method in class io.grpc.internal.SerializingExecutor
- run() - Method in class io.grpc.internal.ServerImpl.ContextCloser
- run() - Method in class io.grpc.protobuf.services.ProtoReflectionServiceV1.ProtoReflectionStreamObserver
- run() - Method in interface io.grpc.servlet.AsyncServletOutputStreamWriter.ActionItem
- run() - Method in interface io.grpc.servlet.jakarta.AsyncServletOutputStreamWriter.ActionItem
- run() - Method in class io.grpc.SynchronizationContext.ManagedRunnable
- run() - Method in class io.grpc.util.AdvancedTlsX509KeyManager.LoadFilePathExecution
- run() - Method in class io.grpc.util.AdvancedTlsX509TrustManager.LoadFilePathExecution
- run() - Method in class io.grpc.util.OutlierDetectionLoadBalancer.DetectionTimer
- run(boolean) - Method in interface io.grpc.internal.MigratingThreadDeframer.Op
- run(Channel) - Method in class io.grpc.netty.SendGrpcFrameCommand
- run(Channel) - Method in class io.grpc.netty.WriteQueue.AbstractQueuedCommand
- run(Channel) - Method in interface io.grpc.netty.WriteQueue.QueuedCommand
- run(Channel) - Method in class io.grpc.netty.WriteQueue.RunnableCommand
- run(Runnable) - Method in class io.grpc.Context
-
Immediately run a
Runnable
with this context as theContext.current()
context. - runAtNanos - Variable in class io.grpc.internal.Rescheduler
- runInContext() - Method in class io.grpc.internal.ContextRunnable
- runInContext() - Method in class io.grpc.internal.DelayedClientCall.CloseListenerRunnable
- runInExecutor() - Method in class io.grpc.internal.ConnectivityStateManager.Listener
- runnable - Variable in class io.grpc.internal.ApplicationThreadDeframer.InitializingMessageProducer
- runnable - Variable in class io.grpc.internal.Rescheduler
- runnable - Variable in class io.grpc.netty.WriteQueue.RunnableCommand
- runnable - Variable in class io.grpc.SynchronizationContext.ScheduledHandle
- RunnableCommand(Runnable) - Constructor for class io.grpc.netty.WriteQueue.RunnableCommand
- running - Variable in class io.grpc.protobuf.services.HealthCheckingLoadBalancerFactory.HealthCheckState
- RUNNING - Static variable in class io.grpc.internal.SerializingExecutor
- runOnExpiration(Runnable, ScheduledExecutorService) - Method in class io.grpc.Deadline
-
Schedule a task to be run when the deadline expires.
- runOnTransportThread(Runnable) - Method in interface io.grpc.internal.ApplicationThreadDeframerListener.TransportExecutor
- runOnTransportThread(Runnable) - Method in class io.grpc.netty.NettyClientStream.TransportState
- runOnTransportThread(Runnable) - Method in class io.grpc.netty.NettyServerStream.TransportState
- runOnTransportThread(Runnable) - Method in class io.grpc.servlet.jakarta.ServletServerStream.ServletTransportState
- runOnTransportThread(Runnable) - Method in class io.grpc.servlet.ServletServerStream.ServletTransportState
- runOrBuffer(AsyncServletOutputStreamWriter.ActionItem) - Method in class io.grpc.servlet.AsyncServletOutputStreamWriter
-
Either execute the write action directly, or buffer the action and let the container thread drain it.
- runOrBuffer(AsyncServletOutputStreamWriter.ActionItem) - Method in class io.grpc.servlet.jakarta.AsyncServletOutputStreamWriter
-
Either execute the write action directly, or buffer the action and let the container thread drain it.
- runQueue - Variable in class io.grpc.internal.SerializingExecutor
-
A list of Runnables to be run in order.
- runQuietly(Runnable) - Static method in class io.grpc.stub.ClientCalls.ThreadlessExecutor
- runState - Variable in class io.grpc.internal.SerializingExecutor
- runStateCompareAndSet(SerializingExecutor, int, int) - Method in class io.grpc.internal.SerializingExecutor.AtomicHelper
- runStateCompareAndSet(SerializingExecutor, int, int) - Method in class io.grpc.internal.SerializingExecutor.FieldUpdaterAtomicHelper
- runStateCompareAndSet(SerializingExecutor, int, int) - Method in class io.grpc.internal.SerializingExecutor.SynchronizedAtomicHelper
- runStateSet(SerializingExecutor, int) - Method in class io.grpc.internal.SerializingExecutor.AtomicHelper
- runStateSet(SerializingExecutor, int) - Method in class io.grpc.internal.SerializingExecutor.FieldUpdaterAtomicHelper
- runStateSet(SerializingExecutor, int) - Method in class io.grpc.internal.SerializingExecutor.SynchronizedAtomicHelper
- runStateUpdater - Variable in class io.grpc.internal.SerializingExecutor.FieldUpdaterAtomicHelper
- runWhereAppropriate(MigratingThreadDeframer.Op) - Method in class io.grpc.internal.MigratingThreadDeframer
- runWhereAppropriate(MigratingThreadDeframer.Op, boolean) - Method in class io.grpc.internal.MigratingThreadDeframer
- runWith(RetriableStream.Substream) - Method in interface io.grpc.internal.RetriableStream.BufferEntry
-
Replays the buffer entry with the given stream.
- runWith(RetriableStream.Substream) - Method in class io.grpc.internal.RetriableStream.StartEntry
S
- sacked - Variable in class io.grpc.InternalChannelz.TcpInfo.Builder
- sacked - Variable in class io.grpc.InternalChannelz.TcpInfo
- safe - Variable in class io.grpc.MethodDescriptor.Builder
- safe - Variable in class io.grpc.MethodDescriptor
- safeCloseMasterListener(Status, ClientStreamListener.RpcProgress, Metadata) - Method in class io.grpc.internal.RetriableStream
- sampledToLocalTracing - Variable in class io.grpc.MethodDescriptor.Builder
- sampledToLocalTracing - Variable in class io.grpc.MethodDescriptor
- saturatedAdd(long, long) - Static method in class io.grpc.internal.JsonUtil
-
Returns the sum of
a
andb
unless it would overflow or underflow in which caseLong.MAX_VALUE
orLong.MIN_VALUE
is returned, respectively. - savedCloseMasterListenerReason - Variable in class io.grpc.internal.RetriableStream
- SavedCloseMasterListenerReason(Status, ClientStreamListener.RpcProgress, Metadata) - Constructor for class io.grpc.internal.RetriableStream.SavedCloseMasterListenerReason
- savedListener - Variable in class io.grpc.internal.DnsNameResolver.Resolve
- savedShutdownNowStatus - Variable in class io.grpc.internal.CallCredentialsApplyingTransportFactory.CallCredentialsApplyingTransport
- savedShutdownStatus - Variable in class io.grpc.internal.CallCredentialsApplyingTransportFactory.CallCredentialsApplyingTransport
- savedValue - Variable in class io.grpc.internal.AtomicBackoff.State
- schedule(Runnable) - Method in class io.grpc.internal.BackoffPolicyRetryScheduler
-
Schedules a future retry operation.
- schedule(Runnable) - Method in interface io.grpc.internal.RetryScheduler
-
A request to schedule a future retry (or retries) for a failed operation.
- schedule(Runnable) - Method in class io.grpc.internal.SerializingExecutor
- schedule(Runnable, long, TimeUnit) - Method in class io.grpc.internal.ManagedChannelImpl.RestrictedScheduledExecutor
- schedule(Runnable, long, TimeUnit, ScheduledExecutorService) - Method in class io.grpc.SynchronizationContext
-
Schedules a task to be added and run via
SynchronizationContext.execute(java.lang.Runnable)
after a delay. - schedule(Callable<V>, long, TimeUnit) - Method in class io.grpc.internal.ManagedChannelImpl.RestrictedScheduledExecutor
- scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class io.grpc.internal.ManagedChannelImpl.RestrictedScheduledExecutor
- scheduleBackoff() - Method in class io.grpc.internal.PickFirstLeafLoadBalancer
-
Only called after all addresses attempted and failed (TRANSIENT_FAILURE).
- scheduleBackoff(Status) - Method in class io.grpc.internal.InternalSubchannel
-
Only called after all addresses attempted and failed (TRANSIENT_FAILURE).
- scheduleConnectionTask - Variable in class io.grpc.internal.PickFirstLeafLoadBalancer
- scheduled - Variable in class io.grpc.netty.WriteQueue
- scheduleDeadlineIfNeeded(ScheduledExecutorService, Deadline) - Method in class io.grpc.internal.DelayedClientCall
- scheduledExecutor - Variable in class io.grpc.internal.InternalSubchannel
- scheduledExecutor - Variable in class io.grpc.internal.ManagedChannelImpl
- scheduledExecutorService - Variable in class io.grpc.inprocess.InProcessChannelBuilder
- scheduledExecutorService - Variable in class io.grpc.internal.BackoffPolicyRetryScheduler
- scheduledExecutorService - Variable in class io.grpc.internal.RetriableStream
- scheduledExecutorService - Variable in class io.grpc.NameResolver.Args.Builder
- scheduledExecutorService - Variable in class io.grpc.NameResolver.Args
- scheduledExecutorService - Variable in class io.grpc.rls.CachingRlsLbClient
- 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.
- scheduledExecutorService(ScheduledExecutorService) - Method in class io.grpc.servlet.jakarta.ServletServerBuilder
-
Provides a custom scheduled executor service to the server builder.
- scheduledExecutorService(ScheduledExecutorService) - Method in class io.grpc.servlet.ServletServerBuilder
-
Provides a custom scheduled executor service to the server builder.
- scheduledFuture - Variable in class io.grpc.rls.CachingRlsLbClient.BackoffCacheEntry
- scheduledHandle - Variable in class io.grpc.internal.BackoffPolicyRetryScheduler
- ScheduledHandle(SynchronizationContext.ManagedRunnable, ScheduledFuture<?>) - Constructor for class io.grpc.SynchronizationContext.ScheduledHandle
- scheduledHedging - Variable in class io.grpc.internal.RetriableStream
- scheduledHedgingRef - Variable in class io.grpc.internal.RetriableStream.HedgingRunnable
- scheduledRetry - Variable in class io.grpc.internal.RetriableStream
- scheduleFlush() - Method in class io.grpc.netty.WriteQueue
-
Schedule a flush on the channel.
- scheduleNextConnection() - Method in class io.grpc.internal.PickFirstLeafLoadBalancer
-
Happy Eyeballs Schedules connection attempt to happen after a delay to the next available address.
- scheduleNextLoadReport() - Method in class io.grpc.grpclb.GrpclbState.LbStream
- scheduler - Variable in class io.grpc.inprocess.InProcessServer
-
Only used to make sure the scheduler has at least one reference.
- scheduler - Variable in class io.grpc.internal.KeepAliveManager
- scheduler - Variable in class io.grpc.internal.MaxConnectionIdleManager
- scheduler - Variable in class io.grpc.internal.Rescheduler
- scheduler - Variable in class io.grpc.servlet.jakarta.ServletServerBuilder
- scheduler - Variable in class io.grpc.servlet.jakarta.ServletServerBuilder.ServerTransportImpl
- scheduler - Variable in class io.grpc.servlet.ServletServerBuilder
- scheduler - Variable in class io.grpc.servlet.ServletServerBuilder.ServerTransportImpl
- schedulerPool - Variable in class io.grpc.inprocess.InProcessServer
-
Defaults to be a SharedResourcePool.
- schedulerPool - Variable in class io.grpc.inprocess.InProcessServerBuilder
- scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class io.grpc.internal.ManagedChannelImpl.RestrictedScheduledExecutor
- scheduleWithFixedDelay(Runnable, long, long, TimeUnit, ScheduledExecutorService) - Method in class io.grpc.SynchronizationContext
-
Schedules a task to be added and run via
SynchronizationContext.execute(java.lang.Runnable)
after an initial delay and then repeated after the delay until cancelled. - schemaDescriptor - Variable in class io.grpc.MethodDescriptor.Builder
- schemaDescriptor - Variable in class io.grpc.MethodDescriptor
- schemaDescriptor - Variable in class io.grpc.ServiceDescriptor.Builder
- schemaDescriptor - Variable in class io.grpc.ServiceDescriptor
- scheme - Variable in class io.grpc.netty.GrpcHttp2HeadersUtils.GrpcHttp2RequestHeaders
- scheme - Variable in class io.grpc.netty.NettyClientStream
- scheme() - Method in class io.grpc.netty.AbstractHttp2Headers
- scheme() - Method in class io.grpc.netty.GrpcHttp2HeadersUtils.GrpcHttp2RequestHeaders
- scheme() - Method in class io.grpc.netty.InternalProtocolNegotiator.ProtocolNegotiatorAdapter
- scheme() - Method in interface io.grpc.netty.ProtocolNegotiator
-
The HTTP/2 scheme to be used when sending
HEADERS
. - scheme() - Method in class io.grpc.netty.ProtocolNegotiators.ClientTlsProtocolNegotiator
- scheme() - Method in class io.grpc.netty.ProtocolNegotiators.PlaintextProtocolNegotiator
- scheme() - Method in class io.grpc.netty.ProtocolNegotiators.PlaintextUpgradeProtocolNegotiator
- scheme(CharSequence) - Method in class io.grpc.netty.AbstractHttp2Headers
- SCHEME - Static variable in class io.grpc.grpclb.SecretGrpclbNameResolverProvider.Provider
- SCHEME - Static variable in class io.grpc.internal.DnsNameResolverProvider
- SCHEME - Static variable in class io.grpc.netty.UdsNameResolverProvider
- SCHEME_HEADER - Static variable in class io.grpc.netty.GrpcHttp2HeadersUtils.GrpcHttp2RequestHeaders
- ScParser - Class in io.grpc.internal
-
The library built-in implementation of service config parser.
- ScParser(boolean, int, int, AutoConfiguredLoadBalancerFactory) - Constructor for class io.grpc.internal.ScParser
-
Creates a parse with global retry settings and an auto configured lb factory.
- secondGoAwayAndClose(ChannelHandlerContext) - Method in class io.grpc.netty.NettyServerHandler.GracefulShutdown
- SecretGrpclbNameResolverProvider - Class in io.grpc.grpclb
-
A provider for
io.grpc.grpclb.GrpclbNameResolver
. - SecretGrpclbNameResolverProvider() - Constructor for class io.grpc.grpclb.SecretGrpclbNameResolverProvider
- SecretGrpclbNameResolverProvider.Provider - Class in io.grpc.grpclb
- SecretRoundRobinLoadBalancerProvider - Class in io.grpc.util
-
Provider for the "round_robin" balancing policy.
- SecretRoundRobinLoadBalancerProvider() - Constructor for class io.grpc.util.SecretRoundRobinLoadBalancerProvider
- SecretRoundRobinLoadBalancerProvider.Provider - Class in io.grpc.util
- security - Variable in class io.grpc.InternalChannelz.SocketStats
- security - Variable in class io.grpc.netty.ProtocolNegotiationEvent
- Security - Class in io.grpc.channelz.v1
-
Security represents details about how secure the socket is.
- Security() - Constructor for class io.grpc.channelz.v1.Security
- Security(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.channelz.v1.Security
- Security(InternalChannelz.OtherSecurity) - Constructor for class io.grpc.InternalChannelz.Security
- Security(InternalChannelz.Tls) - Constructor for class io.grpc.InternalChannelz.Security
- security_ - Variable in class io.grpc.channelz.v1.Socket.Builder
- security_ - Variable in class io.grpc.channelz.v1.Socket
- SECURITY_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.Socket
- Security.Builder - Class in io.grpc.channelz.v1
-
Security represents details about how secure the socket is.
- Security.ModelCase - Enum in io.grpc.channelz.v1
- Security.OtherSecurity - Class in io.grpc.channelz.v1
-
Protobuf type
grpc.channelz.v1.Security.OtherSecurity
- Security.OtherSecurity.Builder - Class in io.grpc.channelz.v1
-
Protobuf type
grpc.channelz.v1.Security.OtherSecurity
- Security.OtherSecurityOrBuilder - Interface in io.grpc.channelz.v1
- Security.Tls - Class in io.grpc.channelz.v1
-
Protobuf type
grpc.channelz.v1.Security.Tls
- Security.Tls.Builder - Class in io.grpc.channelz.v1
-
Protobuf type
grpc.channelz.v1.Security.Tls
- Security.Tls.CipherSuiteCase - Enum in io.grpc.channelz.v1
- Security.TlsOrBuilder - Interface in io.grpc.channelz.v1
- securityBuilder_ - Variable in class io.grpc.channelz.v1.Socket.Builder
- securityInfo - Variable in class io.grpc.netty.NettyClientHandler
- securityInfo - Variable in class io.grpc.netty.NettyServerHandler
- SecurityLevel - Enum in io.grpc
-
The level of security guarantee in communications.
- SecurityLevel() - Constructor for enum io.grpc.SecurityLevel
- SecurityOrBuilder - Interface in io.grpc.channelz.v1
- seekTo(SocketAddress) - Method in class io.grpc.internal.InternalSubchannel.Index
-
Returns false if the needle was not found and the current index was left unchanged.
- seekTo(SocketAddress) - Method in class io.grpc.internal.PickFirstLeafLoadBalancer.Index
-
Returns false if the needle was not found and the current index was left unchanged.
- selectConfig(LoadBalancer.PickSubchannelArgs) - Method in class io.grpc.internal.ManagedChannelServiceConfig.ServiceConfigConvertedSelector
- selectConfig(LoadBalancer.PickSubchannelArgs) - Method in class io.grpc.InternalConfigSelector
-
Selects the config for an PRC.
- selectLbPolicyFromList(List<ServiceConfigUtil.LbConfig>, LoadBalancerRegistry) - Static method in class io.grpc.internal.ServiceConfigUtil
-
Parses and selects a load balancing policy from a non-empty list of raw configs.
- sendErrorResponse(ServerReflectionRequest, Status.Code, String) - Method in class io.grpc.protobuf.services.ProtoReflectionServiceV1.ProtoReflectionStreamObserver
- sendGrpcFrame(ChannelHandlerContext, SendGrpcFrameCommand, ChannelPromise) - Method in class io.grpc.netty.NettyClientHandler
-
Sends the given GRPC frame for the stream.
- sendGrpcFrame(ChannelHandlerContext, SendGrpcFrameCommand, ChannelPromise) - Method in class io.grpc.netty.NettyServerHandler
-
Sends the given gRPC frame to the client.
- SendGrpcFrameCommand - Class in io.grpc.netty
-
Command sent from the transport to the Netty channel to send a GRPC frame to the remote endpoint.
- SendGrpcFrameCommand(StreamIdHolder, ByteBuf, boolean) - Constructor for class io.grpc.netty.SendGrpcFrameCommand
- sendHeaders(Metadata) - Method in class io.grpc.internal.ServerCallImpl
- sendHeaders(Metadata) - Method in class io.grpc.PartialForwardingServerCall
- sendHeaders(Metadata) - Method in class io.grpc.ServerCall
-
Send response header metadata prior to sending a response message.
- sendHeaders(Metadata) - Method in class io.grpc.stub.MetadataUtils.MetadataAttachingServerInterceptor.MetadataAttachingServerCall
- sendHeaders(Metadata) - Method in class io.grpc.util.TransmitStatusRuntimeExceptionInterceptor.SerializingServerCall
- sendHeadersCalled - Variable in class io.grpc.internal.ServerCallImpl
- sendHeadersInternal(Metadata) - Method in class io.grpc.internal.ServerCallImpl
- sendInitialConnectionWindow() - Method in class io.grpc.netty.AbstractNettyHandler
-
Sends initial connection window to the remote endpoint if necessary.
- sendLoadReport() - Method in class io.grpc.grpclb.GrpclbState.LbStream
- sendMessage(ReqT) - Method in class io.grpc.ClientCall
-
Send a request message to the server.
- sendMessage(ReqT) - Method in class io.grpc.ForwardingClientCall
- sendMessage(ReqT) - Method in class io.grpc.internal.ClientCallImpl
- sendMessage(ReqT) - Method in class io.grpc.internal.DelayedClientCall
- sendMessage(ReqT) - Method in class io.grpc.internal.RetriableStream
- sendMessage(RespT) - Method in class io.grpc.ForwardingServerCall
- sendMessage(RespT) - Method in class io.grpc.internal.ServerCallImpl
- sendMessage(RespT) - Method in class io.grpc.ServerCall
-
Send a response message.
- sendMessage(RespT) - Method in class io.grpc.util.TransmitStatusRuntimeExceptionInterceptor.SerializingServerCall
- sendMessageInternal(ReqT) - Method in class io.grpc.internal.ClientCallImpl
- sendMessageInternal(RespT) - Method in class io.grpc.internal.ServerCallImpl
- sendPing - Variable in class io.grpc.internal.KeepAliveManager
- sendPing(ChannelHandlerContext) - Method in class io.grpc.netty.AbstractNettyHandler.FlowControlPinger
- SendPingCommand - Class in io.grpc.netty
-
Command sent from the transport to the Netty channel to send a PING frame.
- SendPingCommand(ClientTransport.PingCallback, Executor) - Constructor for class io.grpc.netty.SendPingCommand
- sendPingFrame(ChannelHandlerContext, SendPingCommand, ChannelPromise) - Method in class io.grpc.netty.NettyClientHandler
- sendPingFrameTraced(ChannelHandlerContext, SendPingCommand, ChannelPromise) - Method in class io.grpc.netty.NettyClientHandler
-
Sends a PING frame.
- sendResponseHeaders(ChannelHandlerContext, SendResponseHeadersCommand, ChannelPromise) - Method in class io.grpc.netty.NettyServerHandler
-
Sends the response headers to the client.
- SendResponseHeadersCommand - Class in io.grpc.netty
-
Command sent from the transport to the Netty channel to send response headers to the client.
- SendResponseHeadersCommand(StreamIdHolder, Http2Headers, Status) - Constructor for class io.grpc.netty.SendResponseHeadersCommand
- sentHeaders - Variable in class io.grpc.stub.ServerCalls.ServerCallStreamObserverImpl
- sequence - Variable in class io.grpc.util.RoundRobinLoadBalancer
- SEQUENCE_ID_WITHIN_CALL_FIELD_NUMBER - Static variable in class io.grpc.binarylog.v1.GrpcLogEntry
- sequenceIdWithinCall_ - Variable in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
- sequenceIdWithinCall_ - Variable in class io.grpc.binarylog.v1.GrpcLogEntry
- sequenceNumbers - Variable in class io.grpc.internal.SpiffeUtil.SpiffeBundle
- serialize() - Method in class io.grpc.Metadata
-
Serialize all the metadata entries.
- serialize(Metadata) - Static method in class io.grpc.InternalMetadata
- serialized - Variable in class io.grpc.Metadata.LazyValue
- serializeHeadersWithCommasInBin(byte[][], int) - Static method in class io.grpc.internal.TransportFrameUtil
- serializePartial() - Method in class io.grpc.Metadata
-
Serializes all metadata entries, leaving some values as
InputStream
s. - serializePartial(Metadata) - Static method in class io.grpc.InternalMetadata
-
Serializes all metadata entries, leaving some values as
InputStream
s. - SerializeReentrantCallsDirectExecutor - Class in io.grpc.internal
-
Executes a task directly in the calling thread, unless it's a reentrant call in which case the task is enqueued and executed once the calling task completes.
- SerializeReentrantCallsDirectExecutor() - Constructor for class io.grpc.internal.SerializeReentrantCallsDirectExecutor
- serializesToStreams() - Method in class io.grpc.Metadata.Key
-
Returns whether this key will be serialized to bytes lazily.
- serializesToStreams() - Method in class io.grpc.Metadata.LazyStreamBinaryKey
- serializingExecutor - Variable in class io.grpc.internal.Rescheduler
- serializingExecutor - Variable in class io.grpc.util.TransmitStatusRuntimeExceptionInterceptor.SerializingServerCall
- SerializingExecutor - Class in io.grpc.internal
- SerializingExecutor(Executor) - Constructor for class io.grpc.internal.SerializingExecutor
-
Creates a SerializingExecutor, running tasks using
executor
. - SerializingExecutor.AtomicHelper - Class in io.grpc.internal
- SerializingExecutor.FieldUpdaterAtomicHelper - Class in io.grpc.internal
- SerializingExecutor.SynchronizedAtomicHelper - Class in io.grpc.internal
- serializingRetries - Variable in class io.grpc.internal.PickFirstLeafLoadBalancer
- SerializingServerCall(ServerCall<ReqT, RespT>) - Constructor for class io.grpc.util.TransmitStatusRuntimeExceptionInterceptor.SerializingServerCall
- serialVersionUID - Static variable in class io.grpc.binarylog.v1.Address
- serialVersionUID - Static variable in class io.grpc.binarylog.v1.ClientHeader
- serialVersionUID - Static variable in class io.grpc.binarylog.v1.GrpcLogEntry
- serialVersionUID - Static variable in class io.grpc.binarylog.v1.Message
- serialVersionUID - Static variable in class io.grpc.binarylog.v1.Metadata
- serialVersionUID - Static variable in class io.grpc.binarylog.v1.MetadataEntry
- serialVersionUID - Static variable in class io.grpc.binarylog.v1.ServerHeader
- serialVersionUID - Static variable in class io.grpc.binarylog.v1.Trailer
- serialVersionUID - Static variable in class io.grpc.channelz.v1.Address.OtherAddress
- serialVersionUID - Static variable in class io.grpc.channelz.v1.Address
- serialVersionUID - Static variable in class io.grpc.channelz.v1.Address.TcpIpAddress
- serialVersionUID - Static variable in class io.grpc.channelz.v1.Address.UdsAddress
- serialVersionUID - Static variable in class io.grpc.channelz.v1.Channel
- serialVersionUID - Static variable in class io.grpc.channelz.v1.ChannelConnectivityState
- serialVersionUID - Static variable in class io.grpc.channelz.v1.ChannelData
- serialVersionUID - Static variable in class io.grpc.channelz.v1.ChannelRef
- serialVersionUID - Static variable in class io.grpc.channelz.v1.ChannelTrace
- serialVersionUID - Static variable in class io.grpc.channelz.v1.ChannelTraceEvent
- serialVersionUID - Static variable in class io.grpc.channelz.v1.GetChannelRequest
- serialVersionUID - Static variable in class io.grpc.channelz.v1.GetChannelResponse
- serialVersionUID - Static variable in class io.grpc.channelz.v1.GetServerRequest
- serialVersionUID - Static variable in class io.grpc.channelz.v1.GetServerResponse
- serialVersionUID - Static variable in class io.grpc.channelz.v1.GetServerSocketsRequest
- serialVersionUID - Static variable in class io.grpc.channelz.v1.GetServerSocketsResponse
- serialVersionUID - Static variable in class io.grpc.channelz.v1.GetServersRequest
- serialVersionUID - Static variable in class io.grpc.channelz.v1.GetServersResponse
- serialVersionUID - Static variable in class io.grpc.channelz.v1.GetSocketRequest
- serialVersionUID - Static variable in class io.grpc.channelz.v1.GetSocketResponse
- serialVersionUID - Static variable in class io.grpc.channelz.v1.GetSubchannelRequest
- serialVersionUID - Static variable in class io.grpc.channelz.v1.GetSubchannelResponse
- serialVersionUID - Static variable in class io.grpc.channelz.v1.GetTopChannelsRequest
- serialVersionUID - Static variable in class io.grpc.channelz.v1.GetTopChannelsResponse
- serialVersionUID - Static variable in class io.grpc.channelz.v1.Security.OtherSecurity
- serialVersionUID - Static variable in class io.grpc.channelz.v1.Security
- serialVersionUID - Static variable in class io.grpc.channelz.v1.Security.Tls
- serialVersionUID - Static variable in class io.grpc.channelz.v1.Server
- serialVersionUID - Static variable in class io.grpc.channelz.v1.ServerData
- serialVersionUID - Static variable in class io.grpc.channelz.v1.ServerRef
- serialVersionUID - Static variable in class io.grpc.channelz.v1.Socket
- serialVersionUID - Static variable in class io.grpc.channelz.v1.SocketData
- serialVersionUID - Static variable in class io.grpc.channelz.v1.SocketOption
- serialVersionUID - Static variable in class io.grpc.channelz.v1.SocketOptionLinger
- serialVersionUID - Static variable in class io.grpc.channelz.v1.SocketOptionTcpInfo
- serialVersionUID - Static variable in class io.grpc.channelz.v1.SocketOptionTimeout
- serialVersionUID - Static variable in class io.grpc.channelz.v1.SocketRef
- serialVersionUID - Static variable in class io.grpc.channelz.v1.Subchannel
- serialVersionUID - Static variable in class io.grpc.channelz.v1.SubchannelRef
- serialVersionUID - Static variable in class io.grpc.health.v1.HealthCheckRequest
- serialVersionUID - Static variable in class io.grpc.health.v1.HealthCheckResponse
- serialVersionUID - Static variable in class io.grpc.HttpConnectProxiedSocketAddress
- serialVersionUID - Static variable in class io.grpc.inprocess.AnonymousInProcessSocketAddress
- serialVersionUID - Static variable in class io.grpc.inprocess.InProcessSocketAddress
- serialVersionUID - Static variable in exception class io.grpc.internal.AutoConfiguredLoadBalancerFactory.PolicyException
- serialVersionUID - Static variable in class io.grpc.InternalChannelz.ServerSocketMap
- serialVersionUID - Static variable in class io.grpc.lb.v1.ClientStats
- serialVersionUID - Static variable in class io.grpc.lb.v1.ClientStatsPerToken
- serialVersionUID - Static variable in class io.grpc.lb.v1.FallbackResponse
- serialVersionUID - Static variable in class io.grpc.lb.v1.InitialLoadBalanceRequest
- serialVersionUID - Static variable in class io.grpc.lb.v1.InitialLoadBalanceResponse
- serialVersionUID - Static variable in class io.grpc.lb.v1.LoadBalanceRequest
- serialVersionUID - Static variable in class io.grpc.lb.v1.LoadBalanceResponse
- serialVersionUID - Static variable in class io.grpc.lb.v1.Server
- serialVersionUID - Static variable in class io.grpc.lb.v1.ServerList
- serialVersionUID - Static variable in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys
- serialVersionUID - Static variable in class io.grpc.lookup.v1.GrpcKeyBuilder.Name
- serialVersionUID - Static variable in class io.grpc.lookup.v1.GrpcKeyBuilder
- serialVersionUID - Static variable in class io.grpc.lookup.v1.HttpKeyBuilder
- serialVersionUID - Static variable in class io.grpc.lookup.v1.NameMatcher
- serialVersionUID - Static variable in class io.grpc.lookup.v1.RouteLookupClusterSpecifier
- serialVersionUID - Static variable in class io.grpc.lookup.v1.RouteLookupConfig
- serialVersionUID - Static variable in class io.grpc.lookup.v1.RouteLookupRequest
- serialVersionUID - Static variable in class io.grpc.lookup.v1.RouteLookupResponse
- serialVersionUID - Static variable in exception class io.grpc.ManagedChannelProvider.ProviderNotFoundException
- serialVersionUID - Static variable in exception class io.grpc.ManagedChannelRegistry.ProviderNotFoundException
- serialVersionUID - Static variable in class io.grpc.netty.UnhelpfulSecurityProvider
- serialVersionUID - Static variable in class io.grpc.ProxiedSocketAddress
- serialVersionUID - Static variable in class io.grpc.reflection.v1.ErrorResponse
- serialVersionUID - Static variable in class io.grpc.reflection.v1.ExtensionNumberResponse
- serialVersionUID - Static variable in class io.grpc.reflection.v1.ExtensionRequest
- serialVersionUID - Static variable in class io.grpc.reflection.v1.FileDescriptorResponse
- serialVersionUID - Static variable in class io.grpc.reflection.v1.ListServiceResponse
- serialVersionUID - Static variable in class io.grpc.reflection.v1.ServerReflectionRequest
- serialVersionUID - Static variable in class io.grpc.reflection.v1.ServerReflectionResponse
- serialVersionUID - Static variable in class io.grpc.reflection.v1.ServiceResponse
- serialVersionUID - Static variable in class io.grpc.reflection.v1alpha.ErrorResponse
- serialVersionUID - Static variable in class io.grpc.reflection.v1alpha.ExtensionNumberResponse
- serialVersionUID - Static variable in class io.grpc.reflection.v1alpha.ExtensionRequest
- serialVersionUID - Static variable in class io.grpc.reflection.v1alpha.FileDescriptorResponse
- serialVersionUID - Static variable in class io.grpc.reflection.v1alpha.ListServiceResponse
- serialVersionUID - Static variable in class io.grpc.reflection.v1alpha.ServerReflectionRequest
- serialVersionUID - Static variable in class io.grpc.reflection.v1alpha.ServerReflectionResponse
- serialVersionUID - Static variable in class io.grpc.reflection.v1alpha.ServiceResponse
- serialVersionUID - Static variable in exception class io.grpc.rls.LbPolicyConfiguration.InvalidChildPolicyConfigException
- serialVersionUID - Static variable in exception class io.grpc.ServerRegistry.ProviderNotFoundException
- serialVersionUID - Static variable in class io.grpc.servlet.GrpcServlet
- serialVersionUID - Static variable in class io.grpc.servlet.jakarta.GrpcServlet
- serialVersionUID - Static variable in exception class io.grpc.StatusException
- serialVersionUID - Static variable in exception class io.grpc.StatusRuntimeException
- server - Variable in class io.grpc.inprocess.AnonymousInProcessSocketAddress
- Server - Class in io.grpc.channelz.v1
-
Server represents a single server.
- Server - Class in io.grpc.lb.v1
-
Contains server information.
- Server - Class in io.grpc
-
Server for listening for and dispatching incoming calls.
- Server() - Constructor for class io.grpc.channelz.v1.Server
- Server() - Constructor for class io.grpc.lb.v1.Server
- Server() - Constructor for class io.grpc.Server
- Server(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.channelz.v1.Server
- Server(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.lb.v1.Server
- server_ - Variable in class io.grpc.channelz.v1.GetServerResponse.Builder
- server_ - Variable in class io.grpc.channelz.v1.GetServerResponse
- server_ - Variable in class io.grpc.channelz.v1.GetServersResponse.Builder
- server_ - Variable in class io.grpc.channelz.v1.GetServersResponse
- SERVER_CONTEXT_KEY - Static variable in class io.grpc.InternalServer
- SERVER_CONTEXT_KEY - Static variable in class io.grpc.Server
- SERVER_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.GetServerResponse
- SERVER_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.GetServersResponse
- SERVER_HEADER - Enum constant in enum io.grpc.binarylog.v1.GrpcLogEntry.PayloadCase
- SERVER_HEADER_FIELD_NUMBER - Static variable in class io.grpc.binarylog.v1.GrpcLogEntry
- SERVER_ID_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.GetServerRequest
- SERVER_ID_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.GetServerSocketsRequest
- SERVER_ID_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.ServerRef
- SERVER_KEEPALIVE_TIME_NANOS_DISABLED - Static variable in class io.grpc.internal.GrpcUtil
-
The magic keepalive time value that disables keepalive.
- SERVER_LIST - Enum constant in enum io.grpc.lb.v1.LoadBalanceResponse.LoadBalanceResponseTypeCase
- SERVER_LIST_FIELD_NUMBER - Static variable in class io.grpc.lb.v1.LoadBalanceResponse
- SERVER_STREAMING - Enum constant in enum io.grpc.MethodDescriptor.MethodType
-
One request message followed by zero or more response messages.
- Server.Builder - Class in io.grpc.channelz.v1
-
Server represents a single server.
- Server.Builder - Class in io.grpc.lb.v1
-
Contains server information.
- Server and client channel setup - Search tag in class io.grpc.inprocess.InProcessServerBuilder
- Section
- serverBuilder - Variable in class io.grpc.ServerProvider.NewServerBuilderResult
- serverBuilder(ServerBuilder<?>) - Static method in class io.grpc.ServerProvider.NewServerBuilderResult
- ServerBuilder<T> - Class in io.grpc
-
A builder for
Server
instances. - ServerBuilder() - Constructor for class io.grpc.ServerBuilder
- serverBuilder_ - Variable in class io.grpc.channelz.v1.GetServerResponse.Builder
- serverBuilder_ - Variable in class io.grpc.channelz.v1.GetServersResponse.Builder
- 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.
- ServerCallExecutorSupplier - Interface in io.grpc
-
Defines what executor handles the server call, based on each RPC call information at runtime.
- ServerCallHandler<RequestT,
ResponseT> - Interface in io.grpc -
Interface to initiate processing of incoming remote calls.
- ServerCallImpl<ReqT,
RespT> - Class in io.grpc.internal - ServerCallImpl(ServerStream, MethodDescriptor<ReqT, RespT>, Metadata, Context.CancellableContext, DecompressorRegistry, CompressorRegistry, CallTracer, Tag) - Constructor for class io.grpc.internal.ServerCallImpl
- ServerCallImpl.ServerStreamListenerImpl<ReqT> - Class in io.grpc.internal
-
All of these callbacks are assumed to called on an application thread, and the caller is responsible for handling thrown exceptions.
- ServerCallInfo() - Constructor for class io.grpc.ServerStreamTracer.ServerCallInfo
- ServerCallInfoImpl<ReqT,
RespT> - Class in io.grpc.internal -
An implementation of
ServerStreamTracer.ServerCallInfo
. - ServerCallInfoImpl(MethodDescriptor<ReqT, RespT>, Attributes, String) - Constructor for class io.grpc.internal.ServerCallInfoImpl
- ServerCallParameters(ServerCallImpl<ReqT, RespT>, ServerCallHandler<ReqT, RespT>) - Constructor for class io.grpc.internal.ServerImpl.ServerTransportListenerImpl.ServerCallParameters
- 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() - Constructor for class io.grpc.stub.ServerCalls
- ServerCalls.BidiStreamingMethod<ReqT,
RespT> - Interface in io.grpc.stub -
Adaptor to a bidirectional streaming method.
- ServerCalls.ClientStreamingMethod<ReqT,
RespT> - Interface in io.grpc.stub -
Adaptor to a client streaming method.
- ServerCalls.NoopStreamObserver<V> - Class in io.grpc.stub
-
No-op implementation of StreamObserver.
- ServerCalls.ServerCallStreamObserverImpl<ReqT,
RespT> - Class in io.grpc.stub - ServerCalls.ServerStreamingMethod<ReqT,
RespT> - Interface in io.grpc.stub -
Adaptor to a server streaming method.
- ServerCalls.StreamingRequestMethod<ReqT,
RespT> - Interface in io.grpc.stub - ServerCalls.StreamingServerCallHandler<ReqT,
RespT> - Class in io.grpc.stub - ServerCalls.StreamingServerCallHandler.StreamingServerCallListener - Class in io.grpc.stub
- ServerCalls.UnaryMethod<ReqT,
RespT> - Interface in io.grpc.stub -
Adaptor to a unary call method.
- ServerCalls.UnaryRequestMethod<ReqT,
RespT> - Interface in io.grpc.stub - ServerCalls.UnaryServerCallHandler<ReqT,
RespT> - Class in io.grpc.stub - ServerCalls.UnaryServerCallHandler.UnaryServerCallListener - Class in io.grpc.stub
- serverCallStarted(ServerCall<?, ?>) - Method in class io.grpc.ServerStreamTracer
-
Deprecated.Implement
ServerStreamTracer.serverCallStarted(ServerCallInfo)
instead. This method will be removed in a future release of gRPC. - serverCallStarted(ServerStreamTracer.ServerCallInfo<?, ?>) - Method in class io.grpc.internal.StatsTraceContext
- serverCallStarted(ServerStreamTracer.ServerCallInfo<?, ?>) - Method in class io.grpc.ServerStreamTracer
-
Called when
ServerCall
is created. - serverCallStreamObserver - Variable in class io.grpc.protobuf.services.ProtoReflectionServiceV1.ProtoReflectionStreamObserver
- ServerCallStreamObserver<RespT> - Class in io.grpc.stub
-
A refinement of
CallStreamObserver
to allows for interaction with call cancellation events on the server side. - ServerCallStreamObserver() - Constructor for class io.grpc.stub.ServerCallStreamObserver
- ServerCallStreamObserverImpl(ServerCall<ReqT, RespT>, boolean) - Constructor for class io.grpc.stub.ServerCalls.ServerCallStreamObserverImpl
- serverCallTracer - Variable in class io.grpc.internal.ServerCallImpl
- serverCallTracer - Variable in class io.grpc.internal.ServerImpl
- ServerChannelLogger() - Constructor for class io.grpc.netty.NettyServerHandler.ServerChannelLogger
- serverClosed(Status, Status) - Method in class io.grpc.inprocess.InProcessTransport.InProcessStream.InProcessClientStream
- ServerCredentials - Class in io.grpc
-
Represents a security configuration to be used for servers.
- ServerCredentials() - Constructor for class io.grpc.ServerCredentials
- ServerData - Class in io.grpc.channelz.v1
-
ServerData is data for a specific Server.
- ServerData() - Constructor for class io.grpc.channelz.v1.ServerData
- ServerData(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.channelz.v1.ServerData
- ServerData.Builder - Class in io.grpc.channelz.v1
-
ServerData is data for a specific Server.
- ServerDataOrBuilder - Interface in io.grpc.channelz.v1
- serverFilterContext(Context) - Method in class io.grpc.internal.StatsTraceContext
- ServerHeader - Class in io.grpc.binarylog.v1
-
Protobuf type
grpc.binarylog.v1.ServerHeader
- ServerHeader() - Constructor for class io.grpc.binarylog.v1.ServerHeader
- ServerHeader(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.binarylog.v1.ServerHeader
- ServerHeader.Builder - Class in io.grpc.binarylog.v1
-
Protobuf type
grpc.binarylog.v1.ServerHeader
- serverHeaderBuilder_ - Variable in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
- ServerHeaderOrBuilder - Interface in io.grpc.binarylog.v1
- serverId_ - Variable in class io.grpc.channelz.v1.GetServerRequest.Builder
- serverId_ - Variable in class io.grpc.channelz.v1.GetServerRequest
- serverId_ - Variable in class io.grpc.channelz.v1.GetServerSocketsRequest.Builder
- serverId_ - Variable in class io.grpc.channelz.v1.GetServerSocketsRequest
- serverId_ - Variable in class io.grpc.channelz.v1.ServerRef.Builder
- serverId_ - Variable in class io.grpc.channelz.v1.ServerRef
- ServerImpl - Class in io.grpc.internal
-
Default implementation of
Server
, for creation by transports. - ServerImpl(ServerImplBuilder, InternalServer, Context) - Constructor for class io.grpc.internal.ServerImpl
-
Construct a server.
- ServerImpl.ContextCloser - Class in io.grpc.internal
- ServerImpl.JumpToApplicationThreadServerStreamListener - Class in io.grpc.internal
-
Dispatches callbacks onto an application-provided executor and correctly propagates exceptions.
- ServerImpl.NoopListener - Class in io.grpc.internal
- ServerImpl.ServerListenerImpl - Class in io.grpc.internal
- ServerImpl.ServerTransportListenerImpl - Class in io.grpc.internal
- ServerImpl.ServerTransportListenerImpl.ServerCallParameters<ReqT,
RespT> - Class in io.grpc.internal - serverImplBuilder - Variable in class io.grpc.inprocess.InProcessServerBuilder
- serverImplBuilder - Variable in class io.grpc.netty.NettyServerBuilder
- serverImplBuilder - Variable in class io.grpc.servlet.jakarta.ServletServerBuilder
- serverImplBuilder - Variable in class io.grpc.servlet.ServletServerBuilder
- ServerImplBuilder - Class in io.grpc.internal
-
Default builder for
Server
instances, for usage in Transport implementations. - ServerImplBuilder(ServerImplBuilder.ClientTransportServersBuilder) - Constructor for class io.grpc.internal.ServerImplBuilder
-
Creates a new server builder with given transport servers provider.
- ServerImplBuilder.ClientTransportServersBuilder - Interface in io.grpc.internal
-
An interface to provide to provide transport specific information for the server.
- ServerImplBuilder.DefaultFallbackRegistry - Class in io.grpc.internal
- ServerInterceptor - Interface in io.grpc
-
Interface for intercepting incoming calls before they are dispatched by
ServerCallHandler
. - ServerInterceptors - Class in io.grpc
-
Utility methods for working with
ServerInterceptor
s. - ServerInterceptors() - Constructor for class io.grpc.ServerInterceptors
- ServerInterceptors.InterceptCallHandler<ReqT,
RespT> - Class in io.grpc - ServerInterceptors.KnownLengthBufferedInputStream - Class in io.grpc
-
BufferedInputStream
that also implementsKnownLength
. - ServerList - Class in io.grpc.lb.v1
-
Protobuf type
grpc.lb.v1.ServerList
- ServerList() - Constructor for class io.grpc.lb.v1.ServerList
- ServerList(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.lb.v1.ServerList
- ServerList(List<InternalInstrumented<InternalChannelz.ServerStats>>, boolean) - Constructor for class io.grpc.InternalChannelz.ServerList
-
Creates an instance.
- ServerList.Builder - Class in io.grpc.lb.v1
-
Protobuf type
grpc.lb.v1.ServerList
- serverListBuilder_ - Variable in class io.grpc.lb.v1.LoadBalanceResponse.Builder
- serverListener - Variable in class io.grpc.servlet.jakarta.ServletServerBuilder.InternalServerImpl
- serverListener - Variable in class io.grpc.servlet.ServletServerBuilder.InternalServerImpl
- ServerListener - Interface in io.grpc.internal
-
A listener to a server for transport creation events.
- ServerListenerImpl() - Constructor for class io.grpc.internal.ServerImpl.ServerListenerImpl
- ServerListOrBuilder - Interface in io.grpc.lb.v1
- serverMaxInboundMetadataSize - Variable in class io.grpc.inprocess.InProcessTransport
- ServerMethodDefinition<ReqT,
RespT> - Class in io.grpc -
Definition of a method exposed by a
Server
. - ServerMethodDefinition(MethodDescriptor<ReqT, RespT>, ServerCallHandler<ReqT, RespT>) - Constructor for class io.grpc.ServerMethodDefinition
- serverNotifyHalfClose - Variable in class io.grpc.inprocess.InProcessTransport.InProcessStream.InProcessClientStream
- ServerOrBuilder - Interface in io.grpc.channelz.v1
- ServerOrBuilder - Interface in io.grpc.lb.v1
- serverPlaintext() - Static method in class io.grpc.netty.InternalProtocolNegotiators
-
Returns a
ProtocolNegotiator
for plaintext server channel. - serverPlaintext() - Static method in class io.grpc.netty.ProtocolNegotiators
-
Create a server plaintext handler for gRPC.
- serverPlaintextFactory() - Static method in class io.grpc.netty.ProtocolNegotiators
-
Create a server plaintext handler factory for gRPC.
- ServerPriorityAccessor() - Constructor for class io.grpc.ServerRegistry.ServerPriorityAccessor
- ServerProvider - Class in io.grpc
-
Provider of servers for transport agnostic consumption.
- ServerProvider() - Constructor for class io.grpc.ServerProvider
- ServerProvider.NewServerBuilderResult - Class in io.grpc
- serverReceiveQueue - Variable in class io.grpc.inprocess.InProcessTransport.InProcessStream.InProcessClientStream
- ServerRef - Class in io.grpc.channelz.v1
-
ServerRef is a reference to a Server.
- ServerRef() - Constructor for class io.grpc.channelz.v1.ServerRef
- ServerRef(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.channelz.v1.ServerRef
- ServerRef.Builder - Class in io.grpc.channelz.v1
-
ServerRef is a reference to a Server.
- ServerReflectionBaseDescriptorSupplier() - Constructor for class io.grpc.reflection.v1.ServerReflectionGrpc.ServerReflectionBaseDescriptorSupplier
- ServerReflectionBaseDescriptorSupplier() - Constructor for class io.grpc.reflection.v1alpha.ServerReflectionGrpc.ServerReflectionBaseDescriptorSupplier
- ServerReflectionBlockingStub(Channel, CallOptions) - Constructor for class io.grpc.reflection.v1.ServerReflectionGrpc.ServerReflectionBlockingStub
- ServerReflectionBlockingStub(Channel, CallOptions) - Constructor for class io.grpc.reflection.v1alpha.ServerReflectionGrpc.ServerReflectionBlockingStub
- ServerReflectionFileDescriptorSupplier() - Constructor for class io.grpc.reflection.v1.ServerReflectionGrpc.ServerReflectionFileDescriptorSupplier
- ServerReflectionFileDescriptorSupplier() - Constructor for class io.grpc.reflection.v1alpha.ServerReflectionGrpc.ServerReflectionFileDescriptorSupplier
- ServerReflectionFutureStub(Channel, CallOptions) - Constructor for class io.grpc.reflection.v1.ServerReflectionGrpc.ServerReflectionFutureStub
- ServerReflectionFutureStub(Channel, CallOptions) - Constructor for class io.grpc.reflection.v1alpha.ServerReflectionGrpc.ServerReflectionFutureStub
- ServerReflectionGrpc - Class in io.grpc.reflection.v1
- ServerReflectionGrpc - Class in io.grpc.reflection.v1alpha
- ServerReflectionGrpc() - Constructor for class io.grpc.reflection.v1.ServerReflectionGrpc
- ServerReflectionGrpc() - Constructor for class io.grpc.reflection.v1alpha.ServerReflectionGrpc
- ServerReflectionGrpc.AsyncService - Interface in io.grpc.reflection.v1
- ServerReflectionGrpc.AsyncService - Interface in io.grpc.reflection.v1alpha
- ServerReflectionGrpc.MethodHandlers<Req,
Resp> - Class in io.grpc.reflection.v1 - ServerReflectionGrpc.MethodHandlers<Req,
Resp> - Class in io.grpc.reflection.v1alpha - ServerReflectionGrpc.ServerReflectionBaseDescriptorSupplier - Class in io.grpc.reflection.v1
- ServerReflectionGrpc.ServerReflectionBaseDescriptorSupplier - Class in io.grpc.reflection.v1alpha
- ServerReflectionGrpc.ServerReflectionBlockingStub - Class in io.grpc.reflection.v1
-
A stub to allow clients to do synchronous rpc calls to service ServerReflection.
- ServerReflectionGrpc.ServerReflectionBlockingStub - Class in io.grpc.reflection.v1alpha
-
A stub to allow clients to do synchronous rpc calls to service ServerReflection.
- ServerReflectionGrpc.ServerReflectionFileDescriptorSupplier - Class in io.grpc.reflection.v1
- ServerReflectionGrpc.ServerReflectionFileDescriptorSupplier - Class in io.grpc.reflection.v1alpha
- ServerReflectionGrpc.ServerReflectionFutureStub - Class in io.grpc.reflection.v1
-
A stub to allow clients to do ListenableFuture-style rpc calls to service ServerReflection.
- ServerReflectionGrpc.ServerReflectionFutureStub - Class in io.grpc.reflection.v1alpha
-
A stub to allow clients to do ListenableFuture-style rpc calls to service ServerReflection.
- ServerReflectionGrpc.ServerReflectionImplBase - Class in io.grpc.reflection.v1
-
Base class for the server implementation of the service ServerReflection.
- ServerReflectionGrpc.ServerReflectionImplBase - Class in io.grpc.reflection.v1alpha
-
Base class for the server implementation of the service ServerReflection.
- ServerReflectionGrpc.ServerReflectionMethodDescriptorSupplier - Class in io.grpc.reflection.v1
- ServerReflectionGrpc.ServerReflectionMethodDescriptorSupplier - Class in io.grpc.reflection.v1alpha
- ServerReflectionGrpc.ServerReflectionStub - Class in io.grpc.reflection.v1
-
A stub to allow clients to do asynchronous rpc calls to service ServerReflection.
- ServerReflectionGrpc.ServerReflectionStub - Class in io.grpc.reflection.v1alpha
-
A stub to allow clients to do asynchronous rpc calls to service ServerReflection.
- ServerReflectionImplBase() - Constructor for class io.grpc.reflection.v1.ServerReflectionGrpc.ServerReflectionImplBase
- ServerReflectionImplBase() - Constructor for class io.grpc.reflection.v1alpha.ServerReflectionGrpc.ServerReflectionImplBase
- serverReflectionIndex - Variable in class io.grpc.protobuf.services.ProtoReflectionServiceV1.ProtoReflectionStreamObserver
- ServerReflectionIndex(List<ServerServiceDefinition>, List<ServerServiceDefinition>) - Constructor for class io.grpc.protobuf.services.ProtoReflectionServiceV1.ServerReflectionIndex
- serverReflectionIndexes - Variable in class io.grpc.protobuf.services.ProtoReflectionServiceV1
- serverReflectionInfo(StreamObserver<ServerReflectionResponse>) - Method in class io.grpc.protobuf.services.ProtoReflectionServiceV1
- serverReflectionInfo(StreamObserver<ServerReflectionResponse>) - Method in interface io.grpc.reflection.v1.ServerReflectionGrpc.AsyncService
-
The reflection service is structured as a bidirectional stream, ensuring all related requests go to a single server.
- serverReflectionInfo(StreamObserver<ServerReflectionResponse>) - Method in class io.grpc.reflection.v1.ServerReflectionGrpc.ServerReflectionStub
-
The reflection service is structured as a bidirectional stream, ensuring all related requests go to a single server.
- serverReflectionInfo(StreamObserver<ServerReflectionResponse>) - Method in interface io.grpc.reflection.v1alpha.ServerReflectionGrpc.AsyncService
-
The reflection service is structured as a bidirectional stream, ensuring all related requests go to a single server.
- serverReflectionInfo(StreamObserver<ServerReflectionResponse>) - Method in class io.grpc.reflection.v1alpha.ServerReflectionGrpc.ServerReflectionStub
-
The reflection service is structured as a bidirectional stream, ensuring all related requests go to a single server.
- ServerReflectionMethodDescriptorSupplier(String) - Constructor for class io.grpc.reflection.v1.ServerReflectionGrpc.ServerReflectionMethodDescriptorSupplier
- ServerReflectionMethodDescriptorSupplier(String) - Constructor for class io.grpc.reflection.v1alpha.ServerReflectionGrpc.ServerReflectionMethodDescriptorSupplier
- ServerReflectionProto - Class in io.grpc.reflection.v1
- ServerReflectionProto - Class in io.grpc.reflection.v1alpha
-
Deprecated.
- ServerReflectionProto() - Constructor for class io.grpc.reflection.v1.ServerReflectionProto
- ServerReflectionProto() - Constructor for class io.grpc.reflection.v1alpha.ServerReflectionProto
-
Deprecated.
- ServerReflectionRequest - Class in io.grpc.reflection.v1
-
The message sent by the client when calling ServerReflectionInfo method.
- ServerReflectionRequest - Class in io.grpc.reflection.v1alpha
-
The message sent by the client when calling ServerReflectionInfo method.
- ServerReflectionRequest() - Constructor for class io.grpc.reflection.v1.ServerReflectionRequest
- ServerReflectionRequest() - Constructor for class io.grpc.reflection.v1alpha.ServerReflectionRequest
- ServerReflectionRequest(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.reflection.v1.ServerReflectionRequest
- ServerReflectionRequest(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.reflection.v1alpha.ServerReflectionRequest
- ServerReflectionRequest.Builder - Class in io.grpc.reflection.v1
-
The message sent by the client when calling ServerReflectionInfo method.
- ServerReflectionRequest.Builder - Class in io.grpc.reflection.v1alpha
-
The message sent by the client when calling ServerReflectionInfo method.
- ServerReflectionRequest.MessageRequestCase - Enum in io.grpc.reflection.v1
- ServerReflectionRequest.MessageRequestCase - Enum in io.grpc.reflection.v1alpha
- ServerReflectionRequestOrBuilder - Interface in io.grpc.reflection.v1
- ServerReflectionRequestOrBuilder - Interface in io.grpc.reflection.v1alpha
- ServerReflectionResponse - Class in io.grpc.reflection.v1
-
The message sent by the server to answer ServerReflectionInfo method.
- ServerReflectionResponse - Class in io.grpc.reflection.v1alpha
-
The message sent by the server to answer ServerReflectionInfo method.
- ServerReflectionResponse() - Constructor for class io.grpc.reflection.v1.ServerReflectionResponse
- ServerReflectionResponse() - Constructor for class io.grpc.reflection.v1alpha.ServerReflectionResponse
- ServerReflectionResponse(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.reflection.v1.ServerReflectionResponse
- ServerReflectionResponse(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.reflection.v1alpha.ServerReflectionResponse
- ServerReflectionResponse.Builder - Class in io.grpc.reflection.v1
-
The message sent by the server to answer ServerReflectionInfo method.
- ServerReflectionResponse.Builder - Class in io.grpc.reflection.v1alpha
-
The message sent by the server to answer ServerReflectionInfo method.
- ServerReflectionResponse.MessageResponseCase - Enum in io.grpc.reflection.v1
- ServerReflectionResponse.MessageResponseCase - Enum in io.grpc.reflection.v1alpha
- ServerReflectionResponseOrBuilder - Interface in io.grpc.reflection.v1
- ServerReflectionResponseOrBuilder - Interface in io.grpc.reflection.v1alpha
- ServerReflectionStub(Channel, CallOptions) - Constructor for class io.grpc.reflection.v1.ServerReflectionGrpc.ServerReflectionStub
- ServerReflectionStub(Channel, CallOptions) - Constructor for class io.grpc.reflection.v1alpha.ServerReflectionGrpc.ServerReflectionStub
- ServerRefOrBuilder - Interface in io.grpc.channelz.v1
- ServerRegistry - Class in io.grpc
-
Registry of
ServerProvider
s. - ServerRegistry() - Constructor for class io.grpc.ServerRegistry
- ServerRegistry.ProviderNotFoundException - Exception Class in io.grpc
-
Thrown when no suitable
ServerProvider
objects can be found. - ServerRegistry.ServerPriorityAccessor - Class in io.grpc
- serverRequested - Variable in class io.grpc.inprocess.InProcessTransport.InProcessStream.InProcessClientStream
- serverRequested(int) - Method in class io.grpc.inprocess.InProcessTransport.InProcessStream.InProcessClientStream
-
Client requested more messages.
- serverResponseHeaders(byte[][]) - Static method in class io.grpc.netty.GrpcHttp2OutboundHeaders
- serverResponseTrailers(byte[][]) - Static method in class io.grpc.netty.GrpcHttp2OutboundHeaders
- servers - Variable in class io.grpc.InternalChannelz.ServerList
- servers - Variable in class io.grpc.InternalChannelz
- servers_ - Variable in class io.grpc.lb.v1.ServerList.Builder
- servers_ - Variable in class io.grpc.lb.v1.ServerList
- SERVERS_FIELD_NUMBER - Static variable in class io.grpc.lb.v1.ServerList
- serversBuilder_ - Variable in class io.grpc.lb.v1.ServerList.Builder
- serverScheduler - Variable in class io.grpc.inprocess.InProcessTransport
- serverSchedulerPool - Variable in class io.grpc.inprocess.InProcessTransport
- serverSendsOneMessage() - Method in enum io.grpc.MethodDescriptor.MethodType
-
Returns
true
forUNARY
andCLIENT_STREAMING
, which do not permit the server to stream. - ServerServiceDefinition - Class in io.grpc
-
Definition of a service to be exposed via a Server.
- ServerServiceDefinition(ServiceDescriptor, Map<String, ServerMethodDefinition<?, ?>>) - Constructor for class io.grpc.ServerServiceDefinition
- ServerServiceDefinition.Builder - Class in io.grpc
-
Builder for constructing Service instances.
- serverShutdown() - Method in class io.grpc.internal.ServerImpl.ServerListenerImpl
- serverShutdown() - Method in interface io.grpc.internal.ServerListener
-
The server is shutting down.
- serverShutdownCallbackInvoked - Variable in class io.grpc.internal.ServerImpl
-
true
if ServerListenerImpl.serverShutdown() was called. - ServerSocketMap() - Constructor for class io.grpc.InternalChannelz.ServerSocketMap
- 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 - Variable in class io.grpc.inprocess.InProcessTransport.InProcessStream
- serverStream(Http2Stream) - Method in class io.grpc.netty.NettyServerHandler
-
Returns the server stream associated to the given HTTP/2 stream object.
- ServerStream - Interface in io.grpc.internal
-
Extension of
Stream
to support server-side termination semantics. - serverStreamAttributes - Variable in class io.grpc.inprocess.InProcessTransport
- serverStreaming - Variable in class io.grpc.stub.ServerCalls.UnaryServerCallHandler
- serverStreamingOrBidi - Variable in class io.grpc.stub.ServerCalls.ServerCallStreamObserverImpl
- serverStreamListener - Variable in class io.grpc.inprocess.InProcessTransport.InProcessStream.InProcessClientStream
- ServerStreamListener - Interface in io.grpc.internal
-
An observer of server-side stream events.
- ServerStreamListenerImpl(ServerCallImpl<ReqT, ?>, ServerCall.Listener<ReqT>, Context.CancellableContext) - Constructor for class io.grpc.internal.ServerCallImpl.ServerStreamListenerImpl
- 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.ReadOnlyServerCall<ReqT,
RespT> - Class in io.grpc -
Deprecated.Will be deleted when
ServerStreamTracer.serverCallStarted(ServerCall)
is removed. - ServerStreamTracer.ServerCallInfo<ReqT,
RespT> - Class in io.grpc -
A data class with info about the started
ServerCall
. - serverStreamTracerFactories - Variable in class io.grpc.inprocess.InProcessTransport
- serverTls(SslContext) - Static method in class io.grpc.netty.InternalProtocolNegotiators
-
Returns a
ProtocolNegotiator
that ensures the pipeline is set up so that TLS will be negotiated, the server TLShandler
is added and writes to theChannel
may happen immediately, even before the TLS Handshake is complete. - serverTls(SslContext) - Static method in class io.grpc.netty.ProtocolNegotiators
-
Create a server TLS handler for HTTP/2 capable of using ALPN/NPN.
- serverTls(SslContext, ObjectPool<? extends Executor>) - Static method in class io.grpc.netty.ProtocolNegotiators
-
Create a server TLS handler for HTTP/2 capable of using ALPN/NPN.
- serverTlsFactory(SslContext) - Static method in class io.grpc.netty.ProtocolNegotiators
- ServerTlsHandler(ChannelHandler, SslContext, ObjectPool<? extends Executor>) - Constructor for class io.grpc.netty.ProtocolNegotiators.ServerTlsHandler
- 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
- ServerTransportImpl(ScheduledExecutorService) - Constructor for class io.grpc.servlet.jakarta.ServletServerBuilder.ServerTransportImpl
- ServerTransportImpl(ScheduledExecutorService) - Constructor for class io.grpc.servlet.ServletServerBuilder.ServerTransportImpl
- serverTransportListener - Variable in class io.grpc.inprocess.InProcessTransport
- ServerTransportListener - Interface in io.grpc.internal
-
A observer of a server-side transport for stream creation events.
- ServerTransportListenerImpl(ServerTransport) - Constructor for class io.grpc.internal.ServerImpl.ServerTransportListenerImpl
- serverWriteQueue - Variable in class io.grpc.netty.NettyServerHandler
- service - Variable in class io.grpc.rls.AutoValue_RlsProtoData_ExtraKeys
- service - Variable in class io.grpc.rls.AutoValue_RlsProtoData_GrpcKeyBuilder_Name
- service() - Method in class io.grpc.rls.AutoValue_RlsProtoData_ExtraKeys
- service() - Method in class io.grpc.rls.AutoValue_RlsProtoData_GrpcKeyBuilder_Name
- service() - Method in class io.grpc.rls.RlsProtoData.ExtraKeys
- service() - Method in class io.grpc.rls.RlsProtoData.GrpcKeyBuilder.Name
- service_ - Variable in class io.grpc.health.v1.HealthCheckRequest.Builder
- service_ - Variable in class io.grpc.health.v1.HealthCheckRequest
- service_ - Variable in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys.Builder
- service_ - Variable in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys
- service_ - Variable in class io.grpc.lookup.v1.GrpcKeyBuilder.Name.Builder
- service_ - Variable in class io.grpc.lookup.v1.GrpcKeyBuilder.Name
- service_ - Variable in class io.grpc.reflection.v1.ListServiceResponse.Builder
- service_ - Variable in class io.grpc.reflection.v1.ListServiceResponse
- service_ - Variable in class io.grpc.reflection.v1alpha.ListServiceResponse.Builder
- service_ - Variable in class io.grpc.reflection.v1alpha.ListServiceResponse
- SERVICE_CONFIG_CHOICE_CLIENT_HOSTNAME_KEY - Static variable in class io.grpc.internal.DnsNameResolver
- SERVICE_CONFIG_CHOICE_CLIENT_LANGUAGE_KEY - Static variable in class io.grpc.internal.DnsNameResolver
- SERVICE_CONFIG_CHOICE_KEYS - Static variable in class io.grpc.internal.DnsNameResolver
- SERVICE_CONFIG_CHOICE_PERCENTAGE_KEY - Static variable in class io.grpc.internal.DnsNameResolver
- SERVICE_CONFIG_CHOICE_SERVICE_CONFIG_KEY - Static variable in class io.grpc.internal.DnsNameResolver
- SERVICE_CONFIG_NAME_PREFIX - Static variable in class io.grpc.internal.DnsNameResolver
- SERVICE_CONFIG_PREFIX - Static variable in class io.grpc.internal.DnsNameResolver
- SERVICE_FIELD_NUMBER - Static variable in class io.grpc.health.v1.HealthCheckRequest
- SERVICE_FIELD_NUMBER - Static variable in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys
- SERVICE_FIELD_NUMBER - Static variable in class io.grpc.lookup.v1.GrpcKeyBuilder.Name
- SERVICE_FIELD_NUMBER - Static variable in class io.grpc.reflection.v1.ListServiceResponse
- SERVICE_FIELD_NUMBER - Static variable in class io.grpc.reflection.v1alpha.ListServiceResponse
- SERVICE_NAME - Static variable in class io.grpc.channelz.v1.ChannelzGrpc
- SERVICE_NAME - Static variable in class io.grpc.health.v1.HealthGrpc
- SERVICE_NAME - Static variable in class io.grpc.lb.v1.LoadBalancerGrpc
- SERVICE_NAME - Static variable in class io.grpc.lookup.v1.RouteLookupServiceGrpc
- SERVICE_NAME - Static variable in class io.grpc.reflection.v1.ServerReflectionGrpc
- SERVICE_NAME - Static variable in class io.grpc.reflection.v1alpha.ServerReflectionGrpc
- SERVICE_NAME_ALL_SERVICES - Static variable in class io.grpc.protobuf.services.HealthStatusManager
-
The special "service name" that represent all services on a GRPC server.
- SERVICE_NAME_ALL_SERVICES - Static variable in class io.grpc.services.HealthStatusManager
-
Deprecated.The special "service name" that represent all services on a GRPC server.
- SERVICE_UNKNOWN - Enum constant in enum io.grpc.health.v1.HealthCheckResponse.ServingStatus
-
Used only by the Watch method.
- SERVICE_UNKNOWN_VALUE - Static variable in enum io.grpc.health.v1.HealthCheckResponse.ServingStatus
-
Used only by the Watch method.
- serviceBuilder_ - Variable in class io.grpc.reflection.v1.ListServiceResponse.Builder
- serviceBuilder_ - Variable in class io.grpc.reflection.v1alpha.ListServiceResponse.Builder
- serviceConfig - Variable in class io.grpc.NameResolver.ResolutionResult.Builder
- serviceConfig - Variable in class io.grpc.NameResolver.ResolutionResult
- ServiceConfigConvertedSelector(ManagedChannelServiceConfig) - Constructor for class io.grpc.internal.ManagedChannelServiceConfig.ServiceConfigConvertedSelector
-
Converts the service config to config selector.
- serviceConfigParser - Variable in class io.grpc.internal.DnsNameResolver
- serviceConfigParser - Variable in class io.grpc.NameResolver.Args.Builder
- serviceConfigParser - Variable in class io.grpc.NameResolver.Args
- ServiceConfigParser() - Constructor for class io.grpc.NameResolver.ServiceConfigParser
- ServiceConfigState - Class in io.grpc.internal
-
ServiceConfigState
holds the state of the current service config. - ServiceConfigState(ManagedChannelServiceConfig, boolean) - Constructor for class io.grpc.internal.ServiceConfigState
-
Construct new instance.
- serviceConfigUpdated - Variable in class io.grpc.internal.ManagedChannelImpl
- ServiceConfigUtil - Class in io.grpc.internal
-
Helper utility to work with service configs.
- ServiceConfigUtil() - Constructor for class io.grpc.internal.ServiceConfigUtil
- ServiceConfigUtil.LbConfig - Class in io.grpc.internal
-
A LoadBalancingConfig that includes the policy name (the key) and its raw config value (parsed JSON).
- ServiceConfigUtil.PolicySelection - Class in io.grpc.internal
- serviceDescriptor - Static variable in class io.grpc.channelz.v1.ChannelzGrpc
- serviceDescriptor - Static variable in class io.grpc.health.v1.HealthGrpc
- serviceDescriptor - Static variable in class io.grpc.lb.v1.LoadBalancerGrpc
- serviceDescriptor - Static variable in class io.grpc.lookup.v1.RouteLookupServiceGrpc
- serviceDescriptor - Static variable in class io.grpc.reflection.v1.ServerReflectionGrpc
- serviceDescriptor - Static variable in class io.grpc.reflection.v1alpha.ServerReflectionGrpc
- serviceDescriptor - Variable in class io.grpc.ServerServiceDefinition.Builder
- serviceDescriptor - Variable in class io.grpc.ServerServiceDefinition
- ServiceDescriptor - Class in io.grpc
-
Descriptor for a service.
- ServiceDescriptor(ServiceDescriptor.Builder) - Constructor for class io.grpc.ServiceDescriptor
- 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
-
A builder for a
ServiceDescriptor
. - serviceFileDescriptors - Variable in class io.grpc.protobuf.services.ProtoReflectionServiceV1.FileDescriptorIndex
- serviceImpl - Variable in class io.grpc.channelz.v1.ChannelzGrpc.MethodHandlers
- serviceImpl - Variable in class io.grpc.health.v1.HealthGrpc.MethodHandlers
- serviceImpl - Variable in class io.grpc.lb.v1.LoadBalancerGrpc.MethodHandlers
- serviceImpl - Variable in class io.grpc.lookup.v1.RouteLookupServiceGrpc.MethodHandlers
- serviceImpl - Variable in class io.grpc.reflection.v1.ServerReflectionGrpc.MethodHandlers
- serviceImpl - Variable in class io.grpc.reflection.v1alpha.ServerReflectionGrpc.MethodHandlers
- serviceMap - Variable in class io.grpc.internal.ManagedChannelServiceConfig
- serviceMethodMap - Variable in class io.grpc.internal.ManagedChannelServiceConfig
- serviceName - Variable in class io.grpc.grpclb.GrpclbConfig
- serviceName - Variable in class io.grpc.grpclb.GrpclbState
- serviceName - Variable in class io.grpc.MethodDescriptor
- serviceName - Variable in class io.grpc.protobuf.services.HealthCheckingLoadBalancerFactory.HealthCheckState
- serviceName - Variable in class io.grpc.ServerServiceDefinition.Builder
- serviceNames - Variable in class io.grpc.protobuf.services.ProtoReflectionServiceV1.FileDescriptorIndex
- ServiceProviders - Class in io.grpc
- ServiceProviders() - Constructor for class io.grpc.ServiceProviders
- ServiceProviders.PriorityAccessor<T> - Interface in io.grpc
-
An interface that allows us to get priority information about a provider.
- ServiceResponse - Class in io.grpc.reflection.v1
-
The information of a single service used by ListServiceResponse to answer list_services request.
- ServiceResponse - Class in io.grpc.reflection.v1alpha
-
The information of a single service used by ListServiceResponse to answer list_services request.
- ServiceResponse() - Constructor for class io.grpc.reflection.v1.ServiceResponse
- ServiceResponse() - Constructor for class io.grpc.reflection.v1alpha.ServiceResponse
- ServiceResponse(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.reflection.v1.ServiceResponse
- ServiceResponse(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.reflection.v1alpha.ServiceResponse
- ServiceResponse.Builder - Class in io.grpc.reflection.v1
-
The information of a single service used by ListServiceResponse to answer list_services request.
- ServiceResponse.Builder - Class in io.grpc.reflection.v1alpha
-
The information of a single service used by ListServiceResponse to answer list_services request.
- ServiceResponseOrBuilder - Interface in io.grpc.reflection.v1
- ServiceResponseOrBuilder - Interface in io.grpc.reflection.v1alpha
- services - Variable in class io.grpc.internal.InternalHandlerRegistry.Builder
- services - Variable in class io.grpc.internal.InternalHandlerRegistry
- services - Variable in class io.grpc.util.MutableHandlerRegistry
- SERVING - Enum constant in enum io.grpc.health.v1.HealthCheckResponse.ServingStatus
-
SERVING = 1;
- SERVING_VALUE - Static variable in enum io.grpc.health.v1.HealthCheckResponse.ServingStatus
-
SERVING = 1;
- ServingStatus(int) - Constructor for enum io.grpc.health.v1.HealthCheckResponse.ServingStatus
- servletAdapter - Variable in class io.grpc.servlet.GrpcServlet
- servletAdapter - Variable in class io.grpc.servlet.jakarta.GrpcServlet
- ServletAdapter - Class in io.grpc.servlet.jakarta
-
An adapter that transforms
HttpServletRequest
into gRPC request and lets a gRPC server process it, and transforms the gRPC response intoHttpServletResponse
. - ServletAdapter - Class in io.grpc.servlet
-
An adapter that transforms
HttpServletRequest
into gRPC request and lets a gRPC server process it, and transforms the gRPC response intoHttpServletResponse
. - ServletAdapter(ServerTransportListener, List<? extends ServerStreamTracer.Factory>, int) - Constructor for class io.grpc.servlet.jakarta.ServletAdapter
- ServletAdapter(ServerTransportListener, List<? extends ServerStreamTracer.Factory>, int) - Constructor for class io.grpc.servlet.ServletAdapter
- ServletAdapter.GrpcAsyncListener - Class in io.grpc.servlet.jakarta
- ServletAdapter.GrpcAsyncListener - Class in io.grpc.servlet
- ServletAdapter.GrpcReadListener - Class in io.grpc.servlet.jakarta
- ServletAdapter.GrpcReadListener - Class in io.grpc.servlet
- ServletServerBuilder - Class in io.grpc.servlet.jakarta
-
Builder to build a gRPC server that can run as a servlet.
- ServletServerBuilder - Class in io.grpc.servlet
-
Builder to build a gRPC server that can run as a servlet.
- ServletServerBuilder() - Constructor for class io.grpc.servlet.jakarta.ServletServerBuilder
- ServletServerBuilder() - Constructor for class io.grpc.servlet.ServletServerBuilder
- ServletServerBuilder.InternalServerImpl - Class in io.grpc.servlet.jakarta
- ServletServerBuilder.InternalServerImpl - Class in io.grpc.servlet
- ServletServerBuilder.ServerTransportImpl - Class in io.grpc.servlet.jakarta
- ServletServerBuilder.ServerTransportImpl - Class in io.grpc.servlet
- ServletServerStream - Class in io.grpc.servlet.jakarta
- ServletServerStream - Class in io.grpc.servlet
- ServletServerStream(AsyncContext, StatsTraceContext, int, Attributes, String, InternalLogId) - Constructor for class io.grpc.servlet.jakarta.ServletServerStream
- ServletServerStream(AsyncContext, StatsTraceContext, int, Attributes, String, InternalLogId) - Constructor for class io.grpc.servlet.ServletServerStream
- ServletServerStream.ByteArrayWritableBuffer - Class in io.grpc.servlet.jakarta
- ServletServerStream.ByteArrayWritableBuffer - Class in io.grpc.servlet
- ServletServerStream.GrpcWriteListener - Class in io.grpc.servlet.jakarta
- ServletServerStream.GrpcWriteListener - Class in io.grpc.servlet
- ServletServerStream.ServletTransportState - Class in io.grpc.servlet.jakarta
- ServletServerStream.ServletTransportState - Class in io.grpc.servlet
- ServletServerStream.Sink - Class in io.grpc.servlet.jakarta
- ServletServerStream.Sink - Class in io.grpc.servlet
- ServletServerStream.TrailerSupplier - Class in io.grpc.servlet.jakarta
- ServletServerStream.TrailerSupplier - Class in io.grpc.servlet
- ServletTransportState(int, StatsTraceContext, TransportTracer) - Constructor for class io.grpc.servlet.jakarta.ServletServerStream.ServletTransportState
- ServletTransportState(int, StatsTraceContext, TransportTracer) - Constructor for class io.grpc.servlet.ServletServerStream.ServletTransportState
- set(Attributes.Key<T>, T) - Method in class io.grpc.Attributes.Builder
- set(Headers<? extends CharSequence, ? extends CharSequence, ?>) - Method in class io.grpc.netty.AbstractHttp2Headers
- set(CharSequence, CharSequence) - Method in class io.grpc.netty.AbstractHttp2Headers
- set(CharSequence, CharSequence) - Method in class io.grpc.netty.GrpcHttp2HeadersUtils.GrpcHttp2InboundHeaders
- set(CharSequence, CharSequence...) - Method in class io.grpc.netty.AbstractHttp2Headers
- set(CharSequence, Iterable<? extends CharSequence>) - Method in class io.grpc.netty.AbstractHttp2Headers
- set(RespT) - Method in class io.grpc.stub.ClientCalls.GrpcFuture
- setActive(boolean) - Method in class io.grpc.channelz.v1.SocketOptionLinger.Builder
-
active maps to `struct linger.l_onoff`
- setAdditional(Any) - Method in class io.grpc.channelz.v1.SocketOption.Builder
-
Additional data associated with the socket option.
- setAdditional(Any.Builder) - Method in class io.grpc.channelz.v1.SocketOption.Builder
-
Additional data associated with the socket option.
- setAddress(String) - Method in class io.grpc.binarylog.v1.Address.Builder
-
string address = 2;
- setAddressBytes(ByteString) - Method in class io.grpc.binarylog.v1.Address.Builder
-
string address = 2;
- setAddresses(EquivalentAddressGroup) - Method in class io.grpc.LoadBalancer.CreateSubchannelArgs.Builder
-
The addresses to connect to.
- setAddresses(List<EquivalentAddressGroup>) - Method in class io.grpc.LoadBalancer.CreateSubchannelArgs.Builder
-
The addresses to connect to.
- setAddresses(List<EquivalentAddressGroup>) - Method in class io.grpc.LoadBalancer.ResolvedAddresses.Builder
-
Sets the addresses.
- setAddresses(List<EquivalentAddressGroup>) - Method in class io.grpc.NameResolver.ResolutionResult.Builder
-
Deprecated.Will be superseded by setAddressesOrError
- setAddressesOrError(StatusOr<List<EquivalentAddressGroup>>) - Method in class io.grpc.NameResolver.ResolutionResult.Builder
-
Sets the addresses resolved by name resolution or the error in doing so.
- setAddressResolver(DnsNameResolver.AddressResolver) - Method in class io.grpc.grpclb.GrpclbNameResolver
- setAddressResolver(DnsNameResolver.AddressResolver) - Method in class io.grpc.internal.DnsNameResolver
- setAdvmss(int) - Method in class io.grpc.InternalChannelz.TcpInfo.Builder
- setAll(Attributes) - Method in class io.grpc.Attributes.Builder
- setAll(Headers<? extends CharSequence, ? extends CharSequence, ?>) - Method in class io.grpc.netty.AbstractHttp2Headers
- setAllExtensionNumbersOfType(String) - Method in class io.grpc.reflection.v1.ServerReflectionRequest.Builder
-
Finds the tag numbers used by all known extensions of the given message type, and appends them to ExtensionNumberResponse in an undefined order.
- setAllExtensionNumbersOfType(String) - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest.Builder
-
Finds the tag numbers used by all known extensions of extendee_type, and appends them to ExtensionNumberResponse in an undefined order.
- setAllExtensionNumbersOfTypeBytes(ByteString) - Method in class io.grpc.reflection.v1.ServerReflectionRequest.Builder
-
Finds the tag numbers used by all known extensions of the given message type, and appends them to ExtensionNumberResponse in an undefined order.
- setAllExtensionNumbersOfTypeBytes(ByteString) - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest.Builder
-
Finds the tag numbers used by all known extensions of extendee_type, and appends them to ExtensionNumberResponse in an undefined order.
- setAllExtensionNumbersResponse(ExtensionNumberResponse) - Method in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
-
This message is used to answer all_extension_numbers_of_type requests.
- setAllExtensionNumbersResponse(ExtensionNumberResponse.Builder) - Method in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
-
This message is used to answer all_extension_numbers_of_type requests.
- setAllExtensionNumbersResponse(ExtensionNumberResponse) - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
-
This message is used to answer all_extension_numbers_of_type requst.
- setAllExtensionNumbersResponse(ExtensionNumberResponse.Builder) - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
-
This message is used to answer all_extension_numbers_of_type requst.
- setAllUtilizationMetrics(Map<String, Double>) - Method in class io.grpc.services.MetricRecorder
-
Replace the whole metrics data using the specified map.
- setApplicationUtilizationMetric(double) - Method in class io.grpc.services.MetricRecorder
-
Update the application specific utilization metrics data in the range [0, inf).
- setAto(int) - Method in class io.grpc.InternalChannelz.TcpInfo.Builder
- setAttributes(Attributes) - Method in class io.grpc.LoadBalancer.CreateSubchannelArgs.Builder
-
Attributes provided here will be included in
LoadBalancer.Subchannel.getAttributes()
. - setAttributes(Attributes) - Method in class io.grpc.LoadBalancer.ResolvedAddresses.Builder
-
Sets the attributes.
- setAttributes(Attributes) - Method in class io.grpc.NameResolver.ResolutionResult.Builder
-
Sets the attributes for the addresses resolved by name resolution.
- setAuthority(String) - Method in class io.grpc.binarylog.v1.ClientHeader.Builder
-
A single process may be used to run multiple virtual servers with different identities.
- setAuthority(String) - Method in class io.grpc.inprocess.InProcessTransport.InProcessStream.InProcessClientStream
- 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.DelayedStream
- setAuthority(String) - Method in class io.grpc.internal.ForwardingClientStream
- setAuthority(String) - Method in class io.grpc.internal.NoopClientStream
- setAuthority(String) - Method in class io.grpc.internal.RetriableStream
- setAuthority(String) - Method in class io.grpc.netty.NettyClientStream
- setAuthorityBytes(ByteString) - Method in class io.grpc.binarylog.v1.ClientHeader.Builder
-
A single process may be used to run multiple virtual servers with different identities.
- setAutoTuneFlowControl(boolean) - Method in class io.grpc.netty.AbstractNettyHandler
- setBackoff(int) - Method in class io.grpc.InternalChannelz.TcpInfo.Builder
- setBackoffProvider(BackoffPolicy.Provider) - Method in class io.grpc.rls.CachingRlsLbClient.Builder
- setBaseEjectionTimeNanos(Long) - Method in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig.Builder
-
The base time an address is ejected for.
- setBaseTypeName(String) - Method in class io.grpc.reflection.v1.ExtensionNumberResponse.Builder
-
Full name of the base type, including the package name.
- setBaseTypeName(String) - Method in class io.grpc.reflection.v1alpha.ExtensionNumberResponse.Builder
-
Full name of the base type, including the package name.
- setBaseTypeNameBytes(ByteString) - Method in class io.grpc.reflection.v1.ExtensionNumberResponse.Builder
-
Full name of the base type, including the package name.
- setBaseTypeNameBytes(ByteString) - Method in class io.grpc.reflection.v1alpha.ExtensionNumberResponse.Builder
-
Full name of the base type, including the package name.
- setBinaryLog(BinaryLog) - Method in class io.grpc.ForwardingChannelBuilder
- setBinaryLog(BinaryLog) - Method in class io.grpc.ForwardingChannelBuilder2
- setBinaryLog(BinaryLog) - Method in class io.grpc.ForwardingServerBuilder
- setBinaryLog(BinaryLog) - Method in class io.grpc.internal.ManagedChannelImplBuilder
- setBinaryLog(BinaryLog) - Method in class io.grpc.internal.ServerImplBuilder
- 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.
- setBoolean(CharSequence, boolean) - Method in class io.grpc.netty.AbstractHttp2Headers
- setByte(CharSequence, byte) - Method in class io.grpc.netty.AbstractHttp2Headers
- setCacheSizeBytes(long) - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
Rough indicator of amount of memory to use for the client cache.
- setCall(ClientCall<ReqT, RespT>) - Method in class io.grpc.internal.DelayedClientCall
-
Transfers all pending and future requests and mutations to the given call.
- setCallId(long) - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
Uniquely identifies a call.
- setCallOptions(CallOptions) - Method in class io.grpc.ClientStreamTracer.StreamInfo.Builder
-
Sets the effective CallOptions of the call.
- setCallsFailed(long) - Method in class io.grpc.channelz.v1.ChannelData.Builder
-
The number of calls that have completed with a non-OK status
- setCallsFailed(long) - Method in class io.grpc.channelz.v1.ServerData.Builder
-
The number of incoming calls that have a completed with a non-OK status
- setCallsFailed(long) - Method in class io.grpc.InternalChannelz.ChannelStats.Builder
- setCallsFailed(long) - Method in class io.grpc.InternalChannelz.ServerStats.Builder
- setCallsFinishedWithDrop(int, ClientStatsPerToken) - Method in class io.grpc.lb.v1.ClientStats.Builder
-
The list of dropped calls.
- setCallsFinishedWithDrop(int, ClientStatsPerToken.Builder) - Method in class io.grpc.lb.v1.ClientStats.Builder
-
The list of dropped calls.
- setCallsStarted(long) - Method in class io.grpc.channelz.v1.ChannelData.Builder
-
The number of calls started on the channel
- setCallsStarted(long) - Method in class io.grpc.channelz.v1.ServerData.Builder
-
The number of incoming calls started on the server
- 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.channelz.v1.ChannelData.Builder
-
The number of calls that have completed with an OK status
- setCallsSucceeded(long) - Method in class io.grpc.channelz.v1.ServerData.Builder
-
The number of incoming calls that have completed with an OK status
- 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
- setChannel(int, Channel) - Method in class io.grpc.channelz.v1.GetTopChannelsResponse.Builder
-
list of channels that the connection detail service knows about.
- setChannel(int, Channel.Builder) - Method in class io.grpc.channelz.v1.GetTopChannelsResponse.Builder
-
list of channels that the connection detail service knows about.
- setChannel(Channel) - Method in class io.grpc.channelz.v1.GetChannelResponse.Builder
-
The Channel that corresponds to the requested channel_id.
- setChannel(Channel.Builder) - Method in class io.grpc.channelz.v1.GetChannelResponse.Builder
-
The Channel that corresponds to the requested channel_id.
- setChannelId(long) - Method in class io.grpc.channelz.v1.ChannelRef.Builder
-
The globally unique id for this channel.
- setChannelId(long) - Method in class io.grpc.channelz.v1.GetChannelRequest.Builder
-
channel_id is the identifier of the specific channel to get.
- setChannelLogger(ChannelLogger) - Method in class io.grpc.internal.ClientTransportFactory.ClientTransportOptions
- setChannelLogger(ChannelLogger) - Method in class io.grpc.NameResolver.Args.Builder
- setChannelRef(int, ChannelRef) - Method in class io.grpc.channelz.v1.Channel.Builder
-
There are no ordering guarantees on the order of channel refs.
- setChannelRef(int, ChannelRef) - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
There are no ordering guarantees on the order of channel refs.
- setChannelRef(int, ChannelRef.Builder) - Method in class io.grpc.channelz.v1.Channel.Builder
-
There are no ordering guarantees on the order of channel refs.
- setChannelRef(int, ChannelRef.Builder) - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
There are no ordering guarantees on the order of channel refs.
- setChannelRef(ChannelRef) - Method in class io.grpc.channelz.v1.ChannelTraceEvent.Builder
-
.grpc.channelz.v1.ChannelRef channel_ref = 4;
- setChannelRef(ChannelRef.Builder) - Method in class io.grpc.channelz.v1.ChannelTraceEvent.Builder
-
.grpc.channelz.v1.ChannelRef channel_ref = 4;
- setChannelRef(InternalWithLogId) - Method in class io.grpc.InternalChannelz.ChannelTrace.Event.Builder
- setChannelTrace(InternalChannelz.ChannelTrace) - Method in class io.grpc.InternalChannelz.ChannelStats.Builder
- setChar(CharSequence, char) - Method in class io.grpc.netty.AbstractHttp2Headers
- setChildConfig(Object) - Method in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig.Builder
-
Sets the graceful child switch config the
OutlierDetectionLoadBalancer
delegates to. - setClientHeader(ClientHeader) - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
.grpc.binarylog.v1.ClientHeader client_header = 6;
- setClientHeader(ClientHeader.Builder) - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
.grpc.binarylog.v1.ClientHeader client_header = 6;
- setClientStats(ClientStats) - Method in class io.grpc.lb.v1.LoadBalanceRequest.Builder
-
The client stats should be periodically reported to the load balancer based on the duration defined in the InitialLoadBalanceResponse.
- setClientStats(ClientStats.Builder) - Method in class io.grpc.lb.v1.LoadBalanceRequest.Builder
-
The client stats should be periodically reported to the load balancer based on the duration defined in the InitialLoadBalanceResponse.
- setClientStatsReportInterval(Duration) - Method in class io.grpc.lb.v1.InitialLoadBalanceResponse.Builder
-
This interval defines how often the client should send the client stats to the load balancer.
- setClientStatsReportInterval(Duration.Builder) - Method in class io.grpc.lb.v1.InitialLoadBalanceResponse.Builder
-
This interval defines how often the client should send the client stats to the load balancer.
- setClosedStatus(Status) - Method in class io.grpc.internal.AbstractServerStream.TransportState
-
Stores the
Status
that the application used to close this stream. - setCompression(String) - Method in class io.grpc.internal.ServerCallImpl
- setCompression(String) - Method in class io.grpc.PartialForwardingServerCall
- setCompression(String) - Method in class io.grpc.ServerCall
-
Sets the compression algorithm for this call.
- setCompression(String) - Method in class io.grpc.stub.ServerCalls.ServerCallStreamObserverImpl
- setCompression(String) - Method in class io.grpc.stub.ServerCallStreamObserver
-
Sets the compression algorithm to use for the call.
- setCompression(String) - Method in class io.grpc.util.TransmitStatusRuntimeExceptionInterceptor.SerializingServerCall
- setCompressor(Compressor) - Method in class io.grpc.inprocess.InProcessTransport.InProcessStream.InProcessClientStream
- setCompressor(Compressor) - Method in class io.grpc.inprocess.InProcessTransport.InProcessStream.InProcessServerStream
- setCompressor(Compressor) - Method in class io.grpc.internal.AbstractClientStream.GetFramer
- setCompressor(Compressor) - Method in class io.grpc.internal.AbstractStream
- setCompressor(Compressor) - Method in class io.grpc.internal.DelayedStream
- setCompressor(Compressor) - Method in class io.grpc.internal.ForwardingClientStream
- 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 class io.grpc.internal.RetriableStream
- setCompressor(Compressor) - Method in interface io.grpc.internal.Stream
-
Sets the compressor on the framer.
- setCompressorRegistry(CompressorRegistry) - Method in class io.grpc.internal.ClientCallImpl
- setConfig(OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig) - Method in class io.grpc.util.OutlierDetectionLoadBalancer.EndpointTracker
- setConfig(Object) - Method in class io.grpc.InternalConfigSelector.Result.Builder
-
Sets the parsed config.
- setConfigurators(List<? extends Configurator>) - Method in class io.grpc.ConfiguratorRegistry
-
Sets the configurators in this registry.
- setConfigurators(List<InternalConfigurator>) - Static method in class io.grpc.InternalConfiguratorRegistry
- setContainingType(String) - Method in class io.grpc.reflection.v1.ExtensionRequest.Builder
-
Fully-qualified type name.
- setContainingType(String) - Method in class io.grpc.reflection.v1alpha.ExtensionRequest.Builder
-
Fully-qualified type name.
- setContainingTypeBytes(ByteString) - Method in class io.grpc.reflection.v1.ExtensionRequest.Builder
-
Fully-qualified type name.
- setContainingTypeBytes(ByteString) - Method in class io.grpc.reflection.v1alpha.ExtensionRequest.Builder
-
Fully-qualified type name.
- setCpuUtilizationMetric(double) - Method in class io.grpc.services.MetricRecorder
-
Update the CPU utilization metrics data in the range [0, inf).
- setCreationTimeNanos(long) - Method in class io.grpc.InternalChannelz.ChannelTrace.Builder
- setCreationTimestamp(Timestamp) - Method in class io.grpc.channelz.v1.ChannelTrace.Builder
-
Time that this channel was created.
- setCreationTimestamp(Timestamp.Builder) - Method in class io.grpc.channelz.v1.ChannelTrace.Builder
-
Time that this channel was created.
- setCurrentPicker(LoadBalancer.SubchannelPicker) - Method in class io.grpc.util.MultiChildLoadBalancer.ChildLbState
- setCurrentState(ConnectivityState) - Method in class io.grpc.util.MultiChildLoadBalancer.ChildLbState
- setData(ByteString) - Method in class io.grpc.binarylog.v1.Message.Builder
-
May be truncated or omitted.
- setData(ChannelData) - Method in class io.grpc.channelz.v1.Channel.Builder
-
Data specific to this channel.
- setData(ChannelData) - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
Data specific to this channel.
- setData(ChannelData.Builder) - Method in class io.grpc.channelz.v1.Channel.Builder
-
Data specific to this channel.
- setData(ChannelData.Builder) - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
Data specific to this channel.
- setData(ServerData) - Method in class io.grpc.channelz.v1.Server.Builder
-
The associated data of the Server.
- setData(ServerData.Builder) - Method in class io.grpc.channelz.v1.Server.Builder
-
The associated data of the Server.
- setData(SocketData) - Method in class io.grpc.channelz.v1.Socket.Builder
-
Data specific to this Socket.
- setData(SocketData.Builder) - Method in class io.grpc.channelz.v1.Socket.Builder
-
Data specific to this Socket.
- setDataSizeAndSincePing(int) - Method in class io.grpc.netty.AbstractNettyHandler.FlowControlPinger
- setDataSizeSincePing(int) - Method in class io.grpc.netty.AbstractNettyHandler.FlowControlPinger
- setDeadline(Deadline) - Method in class io.grpc.inprocess.InProcessTransport.InProcessStream.InProcessClientStream
- 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.DelayedStream
- setDeadline(Deadline) - Method in class io.grpc.internal.ForwardingClientStream
- setDeadline(Deadline) - Method in class io.grpc.internal.NoopClientStream
- setDeadline(Deadline) - Method in class io.grpc.internal.RetriableStream
- setDeadlineTicker(Deadline.Ticker) - Method in class io.grpc.internal.ServerImplBuilder
-
Sets a custom deadline ticker.
- setDecompressor(Decompressor) - Method in class io.grpc.inprocess.InProcessTransport.InProcessStream.InProcessServerStream
- 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 class io.grpc.internal.MigratingThreadDeframer
- setDecompressor(Decompressor) - Method in interface io.grpc.internal.ServerStream
-
Sets the decompressor on the deframer.
- setDecompressorRegistry(DecompressorRegistry) - Method in class io.grpc.inprocess.InProcessTransport.InProcessStream.InProcessClientStream
- setDecompressorRegistry(DecompressorRegistry) - Method in class io.grpc.internal.AbstractClientStream
- setDecompressorRegistry(DecompressorRegistry) - Method in class io.grpc.internal.AbstractClientStream.TransportState
- setDecompressorRegistry(DecompressorRegistry) - Method in class io.grpc.internal.ClientCallImpl
- 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.DelayedStream
- setDecompressorRegistry(DecompressorRegistry) - Method in class io.grpc.internal.ForwardingClientStream
- setDecompressorRegistry(DecompressorRegistry) - Method in class io.grpc.internal.NoopClientStream
- setDecompressorRegistry(DecompressorRegistry) - Method in class io.grpc.internal.RetriableStream
- setDefaultPort(int) - Method in class io.grpc.NameResolver.Args.Builder
- setDefaultTarget(String) - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
This value provides a default target to use if needed.
- setDefaultTargetBytes(ByteString) - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
This value provides a default target to use if needed.
- setDelegate(MessageDeframer.Listener) - Method in class io.grpc.internal.MigratingThreadDeframer.MigratingDeframerListener
- setDelegate(LoadBalancer) - Method in class io.grpc.internal.AutoConfiguredLoadBalancerFactory.AutoConfiguredLoadBalancer
- setDescription(String) - Method in class io.grpc.channelz.v1.ChannelTraceEvent.Builder
-
High level description of the event.
- setDescription(String) - Method in class io.grpc.InternalChannelz.ChannelTrace.Event.Builder
- setDescriptionBytes(ByteString) - Method in class io.grpc.channelz.v1.ChannelTraceEvent.Builder
-
High level description of the event.
- setDouble(CharSequence, double) - Method in class io.grpc.netty.AbstractHttp2Headers
- setDrop(boolean) - Method in class io.grpc.lb.v1.Server.Builder
-
Indicates whether this particular request should be dropped by the client.
- setDuration(Duration) - Method in class io.grpc.channelz.v1.SocketOptionLinger.Builder
-
duration maps to `struct linger.l_linger`
- setDuration(Duration) - Method in class io.grpc.channelz.v1.SocketOptionTimeout.Builder
-
.google.protobuf.Duration duration = 1;
- setDuration(Duration.Builder) - Method in class io.grpc.channelz.v1.SocketOptionLinger.Builder
-
duration maps to `struct linger.l_linger`
- setDuration(Duration.Builder) - Method in class io.grpc.channelz.v1.SocketOptionTimeout.Builder
-
.google.protobuf.Duration duration = 1;
- setEagAttributes(Attributes) - Method in class io.grpc.internal.ClientTransportFactory.ClientTransportOptions
-
Sets the non-null EquivalentAddressGroup's attributes.
- setEnableTxt(boolean) - Static method in class io.grpc.grpclb.GrpclbNameResolver
- setEnd(boolean) - Method in class io.grpc.channelz.v1.GetServerSocketsResponse.Builder
-
If set, indicates that the list of sockets is the final list.
- setEnd(boolean) - Method in class io.grpc.channelz.v1.GetServersResponse.Builder
-
If set, indicates that the list of servers is the final list.
- setEnd(boolean) - Method in class io.grpc.channelz.v1.GetTopChannelsResponse.Builder
-
If set, indicates that the list of channels is the final list.
- setEndpointTracker(OutlierDetectionLoadBalancer.EndpointTracker) - Method in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionSubchannel
-
If the
LoadBalancer.Subchannel
is considered for outlier detection the associatedOutlierDetectionLoadBalancer.EndpointTracker
should be set. - setEnforcementPercentage(Integer) - Method in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig.FailurePercentageEjection.Builder
-
Only eject this percentage of outliers.
- setEnforcementPercentage(Integer) - Method in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig.SuccessRateEjection.Builder
-
Only eject this percentage of outliers.
- setEntry(int, MetadataEntry) - Method in class io.grpc.binarylog.v1.Metadata.Builder
-
repeated .grpc.binarylog.v1.MetadataEntry entry = 1;
- setEntry(int, MetadataEntry.Builder) - Method in class io.grpc.binarylog.v1.Metadata.Builder
-
repeated .grpc.binarylog.v1.MetadataEntry entry = 1;
- setEpsMetric(double) - Method in class io.grpc.services.MetricRecorder
-
Update the EPS metrics data in the range [0, inf).
- setErrorCode(int) - Method in class io.grpc.reflection.v1.ErrorResponse.Builder
-
This field uses the error codes defined in grpc::StatusCode.
- setErrorCode(int) - Method in class io.grpc.reflection.v1alpha.ErrorResponse.Builder
-
This field uses the error codes defined in grpc::StatusCode.
- setErrorMessage(String) - Method in class io.grpc.reflection.v1.ErrorResponse.Builder
-
string error_message = 2;
- setErrorMessage(String) - Method in class io.grpc.reflection.v1alpha.ErrorResponse.Builder
-
string error_message = 2;
- setErrorMessageBytes(ByteString) - Method in class io.grpc.reflection.v1.ErrorResponse.Builder
-
string error_message = 2;
- setErrorMessageBytes(ByteString) - Method in class io.grpc.reflection.v1alpha.ErrorResponse.Builder
-
string error_message = 2;
- setErrorResponse(ErrorResponse) - Method in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
-
This message is used when an error occurs.
- setErrorResponse(ErrorResponse.Builder) - Method in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
-
This message is used when an error occurs.
- setErrorResponse(ErrorResponse) - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
-
This message is used when an error occurs.
- setErrorResponse(ErrorResponse.Builder) - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
-
This message is used when an error occurs.
- setEvents(int, ChannelTraceEvent) - Method in class io.grpc.channelz.v1.ChannelTrace.Builder
-
List of events that have occurred on this channel.
- setEvents(int, ChannelTraceEvent.Builder) - Method in class io.grpc.channelz.v1.ChannelTrace.Builder
-
List of events that have occurred on this channel.
- setEvents(List<InternalChannelz.ChannelTrace.Event>) - Method in class io.grpc.InternalChannelz.ChannelTrace.Builder
- setEvictionListener(LruCache.EvictionListener<RlsProtoData.RouteLookupRequest, CachingRlsLbClient.CacheEntry>) - Method in class io.grpc.rls.CachingRlsLbClient.Builder
- setException(Throwable) - Method in class io.grpc.stub.ClientCalls.GrpcFuture
- setExecutor(Executor) - Method in class io.grpc.internal.SerializingExecutor
-
Only call this from this SerializingExecutor Runnable, so that the executor is immediately visible to this SerializingExecutor executor.
- setExtensionNumber(int) - Method in class io.grpc.reflection.v1.ExtensionRequest.Builder
-
int32 extension_number = 2;
- setExtensionNumber(int) - Method in class io.grpc.reflection.v1alpha.ExtensionRequest.Builder
-
int32 extension_number = 2;
- setExtensionNumber(int, int) - Method in class io.grpc.reflection.v1.ExtensionNumberResponse.Builder
-
repeated int32 extension_number = 2;
- setExtensionNumber(int, int) - Method in class io.grpc.reflection.v1alpha.ExtensionNumberResponse.Builder
-
repeated int32 extension_number = 2;
- setExtensionRegistry(ExtensionRegistry) - Static method in class io.grpc.protobuf.ProtoUtils
-
Sets the global registry for proto marshalling shared across all servers and clients.
- setExtensionRegistry(ExtensionRegistryLite) - Static method in class io.grpc.protobuf.lite.ProtoLiteUtils
-
Sets the global registry for proto marshalling shared across all servers and clients.
- setExtraKeys(GrpcKeyBuilder.ExtraKeys) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
-
.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys extra_keys = 3;
- setExtraKeys(GrpcKeyBuilder.ExtraKeys.Builder) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
-
.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys extra_keys = 3;
- setFackets(int) - Method in class io.grpc.InternalChannelz.TcpInfo.Builder
- setFailurePercentageEjection(OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig.FailurePercentageEjection) - Method in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig.Builder
-
Set to enable failure percentage ejection.
- setFallbackResponse(FallbackResponse) - Method in class io.grpc.lb.v1.LoadBalanceResponse.Builder
-
If this field is set, then the client should eagerly enter fallback mode (even if there are existing, healthy connections to backends).
- setFallbackResponse(FallbackResponse.Builder) - Method in class io.grpc.lb.v1.LoadBalanceResponse.Builder
-
If this field is set, then the client should eagerly enter fallback mode (even if there are existing, healthy connections to backends).
- setFileByFilename(String) - Method in class io.grpc.reflection.v1.ServerReflectionRequest.Builder
-
Find a proto file by the file name.
- setFileByFilename(String) - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest.Builder
-
Find a proto file by the file name.
- setFileByFilenameBytes(ByteString) - Method in class io.grpc.reflection.v1.ServerReflectionRequest.Builder
-
Find a proto file by the file name.
- setFileByFilenameBytes(ByteString) - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest.Builder
-
Find a proto file by the file name.
- setFileContainingExtension(ExtensionRequest) - Method in class io.grpc.reflection.v1.ServerReflectionRequest.Builder
-
Find the proto file which defines an extension extending the given message type with the given field number.
- setFileContainingExtension(ExtensionRequest.Builder) - Method in class io.grpc.reflection.v1.ServerReflectionRequest.Builder
-
Find the proto file which defines an extension extending the given message type with the given field number.
- setFileContainingExtension(ExtensionRequest) - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest.Builder
-
Find the proto file which defines an extension extending the given message type with the given field number.
- setFileContainingExtension(ExtensionRequest.Builder) - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest.Builder
-
Find the proto file which defines an extension extending the given message type with the given field number.
- setFileContainingSymbol(String) - Method in class io.grpc.reflection.v1.ServerReflectionRequest.Builder
-
Find the proto file that declares the given fully-qualified symbol name.
- setFileContainingSymbol(String) - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest.Builder
-
Find the proto file that declares the given fully-qualified symbol name.
- setFileContainingSymbolBytes(ByteString) - Method in class io.grpc.reflection.v1.ServerReflectionRequest.Builder
-
Find the proto file that declares the given fully-qualified symbol name.
- setFileContainingSymbolBytes(ByteString) - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest.Builder
-
Find the proto file that declares the given fully-qualified symbol name.
- setFileDescriptorProto(int, ByteString) - Method in class io.grpc.reflection.v1.FileDescriptorResponse.Builder
-
Serialized FileDescriptorProto messages.
- setFileDescriptorProto(int, ByteString) - Method in class io.grpc.reflection.v1alpha.FileDescriptorResponse.Builder
-
Serialized FileDescriptorProto messages.
- setFileDescriptorResponse(FileDescriptorResponse) - Method in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
-
This message is used to answer file_by_filename, file_containing_symbol, file_containing_extension requests with transitive dependencies.
- setFileDescriptorResponse(FileDescriptorResponse.Builder) - Method in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
-
This message is used to answer file_by_filename, file_containing_symbol, file_containing_extension requests with transitive dependencies.
- setFileDescriptorResponse(FileDescriptorResponse) - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
-
This message is used to answer file_by_filename, file_containing_symbol, file_containing_extension requests with transitive dependencies.
- setFileDescriptorResponse(FileDescriptorResponse.Builder) - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
-
This message is used to answer file_by_filename, file_containing_symbol, file_containing_extension requests with transitive dependencies.
- setFilename(String) - Method in class io.grpc.channelz.v1.Address.UdsAddress.Builder
-
string filename = 1;
- setFilenameBytes(ByteString) - Method in class io.grpc.channelz.v1.Address.UdsAddress.Builder
-
string filename = 1;
- setFloat(CharSequence, float) - Method in class io.grpc.netty.AbstractHttp2Headers
- setFlowControlWindowReader(TransportTracer.FlowControlReader) - Method in class io.grpc.internal.TransportTracer
-
Registers a
TransportTracer.FlowControlReader
that can be used to read the local and remote flow control window sizes. - setForceHeapBuffer(boolean) - Method in class io.grpc.netty.NettyServerBuilder
-
Force using heap buffer when custom allocator is enabled.
- setForceHeapBuffer(NettyServerBuilder, boolean) - Static method in class io.grpc.netty.InternalNettyServerBuilder
- 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.inprocess.InProcessTransport.InProcessStream.InProcessClientStream
- setFullStreamDecompression(boolean) - Method in class io.grpc.internal.AbstractClientStream
- setFullStreamDecompression(boolean) - Method in class io.grpc.internal.AbstractClientStream.TransportState
- setFullStreamDecompression(boolean) - Method in class io.grpc.internal.ClientCallImpl
- 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.DelayedStream
- setFullStreamDecompression(boolean) - Method in class io.grpc.internal.ForwardingClientStream
- setFullStreamDecompression(boolean) - Method in class io.grpc.internal.NoopClientStream
- setFullStreamDecompression(boolean) - Method in class io.grpc.internal.RetriableStream
- 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
- setFullStreamDecompressor(GzipInflatingBuffer) - Method in class io.grpc.internal.MigratingThreadDeframer
- setFuture(Future<?>) - Method in class io.grpc.internal.RetriableStream.FutureCanceller
- setGrpcKeybuilders(int, GrpcKeyBuilder) - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
Unordered specifications for constructing keys for gRPC requests.
- setGrpcKeybuilders(int, GrpcKeyBuilder.Builder) - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
Unordered specifications for constructing keys for gRPC requests.
- setHeaderData(String) - Method in class io.grpc.lookup.v1.RouteLookupResponse.Builder
-
Optional header value to pass along to AFE in the X-Google-RLS-Data header.
- setHeaderDataBytes(ByteString) - Method in class io.grpc.lookup.v1.RouteLookupResponse.Builder
-
Optional header value to pass along to AFE in the X-Google-RLS-Data header.
- setHeaders(int, NameMatcher) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
-
Extract keys from all listed headers.
- setHeaders(int, NameMatcher) - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
-
List of headers to try to match.
- setHeaders(int, NameMatcher.Builder) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
-
Extract keys from all listed headers.
- setHeaders(int, NameMatcher.Builder) - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
-
List of headers to try to match.
- setHealthCheckedService(String) - Method in class io.grpc.protobuf.services.HealthCheckingLoadBalancerFactory.HelperImpl
- setHelper(LoadBalancer.Helper) - Method in class io.grpc.rls.CachingRlsLbClient.Builder
- setHelper(InternalNettySocketSupport.InternalHelper) - Static method in class io.grpc.netty.InternalNettySocketSupport
- setHelper(NettySocketSupport.Helper) - Static method in class io.grpc.netty.NettySocketSupport
- setHistorySeconds(int) - Method in class io.grpc.rls.AdaptiveThrottler.Builder
- setHost(String) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys.Builder
-
string host = 1;
- setHost(String) - Method in class io.grpc.reflection.v1.ServerReflectionRequest.Builder
-
string host = 1;
- setHost(String) - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest.Builder
-
string host = 1;
- setHostBytes(ByteString) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys.Builder
-
string host = 1;
- setHostBytes(ByteString) - Method in class io.grpc.reflection.v1.ServerReflectionRequest.Builder
-
string host = 1;
- setHostBytes(ByteString) - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest.Builder
-
string host = 1;
- setHostPatterns(int, String) - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
-
host_pattern is an ordered list of host template patterns for the desired value.
- setHttp2Stream(Http2Stream) - Method in class io.grpc.netty.NettyClientStream.TransportState
-
Sets the underlying Netty
Http2Stream
for this stream. - setHttpConnectProxiedSocketAddress(HttpConnectProxiedSocketAddress) - Method in class io.grpc.internal.ClientTransportFactory.ClientTransportOptions
- setHttpKeybuilders(int, HttpKeyBuilder) - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
Ordered specifications for constructing keys for HTTP requests.
- setHttpKeybuilders(int, HttpKeyBuilder.Builder) - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
Ordered specifications for constructing keys for HTTP requests.
- setId(int) - Method in class io.grpc.netty.NettyClientStream.TransportState
- setIdempotent(boolean) - Method in class io.grpc.MethodDescriptor.Builder
-
Sets whether the method is idempotent.
- setInitialBackoffNanos(long) - Method in class io.grpc.internal.ExponentialBackoffPolicy
- setInitialRequest(InitialLoadBalanceRequest) - Method in class io.grpc.lb.v1.LoadBalanceRequest.Builder
-
This message should be sent on the first request to the load balancer.
- setInitialRequest(InitialLoadBalanceRequest.Builder) - Method in class io.grpc.lb.v1.LoadBalanceRequest.Builder
-
This message should be sent on the first request to the load balancer.
- setInitialResponse(InitialLoadBalanceResponse) - Method in class io.grpc.lb.v1.LoadBalanceResponse.Builder
-
This message should be sent on the first response to the client.
- setInitialResponse(InitialLoadBalanceResponse.Builder) - Method in class io.grpc.lb.v1.LoadBalanceResponse.Builder
-
This message should be sent on the first response to the client.
- setInt(CharSequence, int) - Method in class io.grpc.netty.AbstractHttp2Headers
- setInterceptor(ClientInterceptor) - Method in class io.grpc.InternalConfigSelector.Result.Builder
-
Sets the interceptor.
- setIntervalNanos(Long) - Method in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig.Builder
-
The interval between outlier detection sweeps.
- setIpAddress(ByteString) - Method in class io.grpc.channelz.v1.Address.TcpIpAddress.Builder
-
Either the IPv4 or IPv6 address in bytes.
- setIpAddress(ByteString) - Method in class io.grpc.lb.v1.Server.Builder
-
A resolved address for the server, serialized in network-byte-order.
- setIpPort(int) - Method in class io.grpc.binarylog.v1.Address.Builder
-
only for TYPE_IPV4 and TYPE_IPV6
- setIsTransparentRetry(boolean) - Method in class io.grpc.ClientStreamTracer.StreamInfo.Builder
-
Sets whether the stream is a transparent retry.
- setJitter(double) - Method in class io.grpc.internal.ExponentialBackoffPolicy
- setKeepAliveManagerForTest(KeepAliveManager) - Method in class io.grpc.netty.NettyServerHandler
- setKeepAlivesSent(long) - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The number of keep alives sent.
- setKey(String) - Method in class io.grpc.binarylog.v1.MetadataEntry.Builder
-
string key = 1;
- setKey(String) - Method in class io.grpc.lookup.v1.NameMatcher.Builder
-
The name that will be used in the RLS key_map to refer to this value.
- setKeyBytes(ByteString) - Method in class io.grpc.binarylog.v1.MetadataEntry.Builder
-
string key = 1;
- setKeyBytes(ByteString) - Method in class io.grpc.lookup.v1.NameMatcher.Builder
-
The name that will be used in the RLS key_map to refer to this value.
- 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
- setLastCallStartedTimestamp(Timestamp) - Method in class io.grpc.channelz.v1.ChannelData.Builder
-
The last time a call was started on the channel.
- setLastCallStartedTimestamp(Timestamp) - Method in class io.grpc.channelz.v1.ServerData.Builder
-
The last time a call was started on the server.
- setLastCallStartedTimestamp(Timestamp.Builder) - Method in class io.grpc.channelz.v1.ChannelData.Builder
-
The last time a call was started on the channel.
- setLastCallStartedTimestamp(Timestamp.Builder) - Method in class io.grpc.channelz.v1.ServerData.Builder
-
The last time a call was started on the server.
- setLastDataRecv(int) - Method in class io.grpc.InternalChannelz.TcpInfo.Builder
- setLastDataSent(int) - Method in class io.grpc.InternalChannelz.TcpInfo.Builder
- setLastLocalStreamCreatedTimestamp(Timestamp) - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The last time a stream was created by this endpoint.
- setLastLocalStreamCreatedTimestamp(Timestamp.Builder) - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The last time a stream was created by this endpoint.
- setLastMessageReceivedTimestamp(Timestamp) - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The last time a message was received by this endpoint.
- setLastMessageReceivedTimestamp(Timestamp.Builder) - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The last time a message was received by this endpoint.
- setLastMessageSentTimestamp(Timestamp) - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The last time a message was sent by this endpoint.
- setLastMessageSentTimestamp(Timestamp.Builder) - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The last time a message was sent by this endpoint.
- setLastRemoteStreamCreatedTimestamp(Timestamp) - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The last time a stream was created by the remote endpoint.
- setLastRemoteStreamCreatedTimestamp(Timestamp.Builder) - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The last time a stream was created by the remote endpoint.
- setLbPolicyConfig(LbPolicyConfiguration) - Method in class io.grpc.rls.CachingRlsLbClient.Builder
- setLength(int) - Method in class io.grpc.binarylog.v1.Message.Builder
-
Length of the message.
- setListener(ClientStreamListener) - Method in class io.grpc.inprocess.InProcessTransport.InProcessStream.InProcessServerStream
- setListener(ClientStreamListener) - Method in class io.grpc.internal.AbstractClientStream.TransportState
- setListener(MessageDeframer.Listener) - Method in class io.grpc.internal.MessageDeframer
- setListener(ServerStreamListener) - Method in class io.grpc.inprocess.InProcessTransport.InProcessStream.InProcessClientStream
- setListener(ServerStreamListener) - Method in class io.grpc.inprocess.InProcessTransport.InProcessStream.InProcessServerStream
- 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 class io.grpc.internal.ServerImpl.JumpToApplicationThreadServerStreamListener
- setListener(ServerStreamListener) - Method in interface io.grpc.internal.ServerStream
-
Sets the server stream listener.
- setListenSocket(int, SocketRef) - Method in class io.grpc.channelz.v1.Server.Builder
-
The sockets that the server is listening on.
- setListenSocket(int, SocketRef.Builder) - Method in class io.grpc.channelz.v1.Server.Builder
-
The sockets that the server is listening on.
- setListServices(String) - Method in class io.grpc.reflection.v1.ServerReflectionRequest.Builder
-
List the full names of registered services.
- setListServices(String) - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest.Builder
-
List the full names of registered services.
- setListServicesBytes(ByteString) - Method in class io.grpc.reflection.v1.ServerReflectionRequest.Builder
-
List the full names of registered services.
- setListServicesBytes(ByteString) - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest.Builder
-
List the full names of registered services.
- setListServicesResponse(ListServiceResponse) - Method in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
-
This message is used to answer list_services requests.
- setListServicesResponse(ListServiceResponse.Builder) - Method in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
-
This message is used to answer list_services requests.
- setListServicesResponse(ListServiceResponse) - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
-
This message is used to answer list_services request.
- setListServicesResponse(ListServiceResponse.Builder) - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
-
This message is used to answer list_services request.
- setLoadBalanceToken(String) - Method in class io.grpc.lb.v1.ClientStatsPerToken.Builder
-
See Server.load_balance_token.
- setLoadBalanceToken(String) - Method in class io.grpc.lb.v1.Server.Builder
-
An opaque but printable token for load reporting.
- setLoadBalanceTokenBytes(ByteString) - Method in class io.grpc.lb.v1.ClientStatsPerToken.Builder
-
See Server.load_balance_token.
- setLoadBalanceTokenBytes(ByteString) - Method in class io.grpc.lb.v1.Server.Builder
-
An opaque but printable token for load reporting.
- setLoadBalancingPolicyConfig(Object) - Method in class io.grpc.LoadBalancer.ResolvedAddresses.Builder
-
Sets the load balancing policy config.
- setLocal(Address) - Method in class io.grpc.channelz.v1.Socket.Builder
-
The locally bound address.
- setLocal(Address.Builder) - Method in class io.grpc.channelz.v1.Socket.Builder
-
The locally bound address.
- setLocalCertificate(ByteString) - Method in class io.grpc.channelz.v1.Security.Tls.Builder
-
the certificate used by this endpoint.
- setLocalFlowControlWindow(Int64Value) - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The amount of window, granted to the local endpoint by the remote endpoint.
- setLocalFlowControlWindow(Int64Value.Builder) - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The amount of window, granted to the local endpoint by the remote endpoint.
- setLogger(GrpcLogEntry.Logger) - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
One of the above Logger enum
- setLoggerValue(int) - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
One of the above Logger enum
- setLong(CharSequence, long) - Method in class io.grpc.netty.AbstractHttp2Headers
- setLong(CharSequence, long) - Method in class io.grpc.netty.GrpcHttp2HeadersUtils.GrpcHttp2InboundHeaders
- setLookupService(String) - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
The name of the lookup service as a gRPC URI.
- setLookupServiceBytes(ByteString) - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
The name of the lookup service as a gRPC URI.
- setLookupServiceTimeout(Duration) - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
Configure a timeout value for lookup service requests.
- setLookupServiceTimeout(Duration.Builder) - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
Configure a timeout value for lookup service requests.
- setLost(int) - Method in class io.grpc.InternalChannelz.TcpInfo.Builder
- setMaxAge(Duration) - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
How long are responses valid for (like HTTP Cache-Control).
- setMaxAge(Duration.Builder) - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
How long are responses valid for (like HTTP Cache-Control).
- setMaxBackoffNanos(long) - Method in class io.grpc.internal.ExponentialBackoffPolicy
- setMaxEjectionPercent(Integer) - Method in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig.Builder
-
The algorithm agnostic maximum percentage of addresses that can be ejected.
- setMaxEjectionTimeNanos(Long) - Method in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig.Builder
-
The longest time an address can be ejected.
- setMaxInboundMessageSize(int) - Method in class io.grpc.inprocess.InProcessTransport.InProcessStream.InProcessClientStream
- setMaxInboundMessageSize(int) - Method in class io.grpc.internal.AbstractClientStream
- setMaxInboundMessageSize(int) - Method in class io.grpc.internal.AbstractStream.TransportState
- 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.DelayedStream
- setMaxInboundMessageSize(int) - Method in class io.grpc.internal.ForwardingClientStream
- setMaxInboundMessageSize(int) - Method in class io.grpc.internal.MessageDeframer
- setMaxInboundMessageSize(int) - Method in class io.grpc.internal.MigratingThreadDeframer
- setMaxInboundMessageSize(int) - Method in class io.grpc.internal.NoopClientStream
- setMaxInboundMessageSize(int) - Method in class io.grpc.internal.RetriableStream
- setMaxOutboundMessageSize(int) - Method in class io.grpc.inprocess.InProcessTransport.InProcessStream.InProcessClientStream
- setMaxOutboundMessageSize(int) - Method in class io.grpc.internal.AbstractClientStream.GetFramer
- 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 class io.grpc.internal.DelayedStream
- setMaxOutboundMessageSize(int) - Method in class io.grpc.internal.ForwardingClientStream
- 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
- setMaxOutboundMessageSize(int) - Method in class io.grpc.internal.RetriableStream
- setMaxResults(long) - Method in class io.grpc.channelz.v1.GetServerSocketsRequest.Builder
-
If non-zero, the server will return a page of results containing at most this many items.
- setMaxResults(long) - Method in class io.grpc.channelz.v1.GetServersRequest.Builder
-
If non-zero, the server will return a page of results containing at most this many items.
- setMaxResults(long) - Method in class io.grpc.channelz.v1.GetTopChannelsRequest.Builder
-
If non-zero, the server will return a page of results containing at most this many items.
- setMemoryUtilizationMetric(double) - Method in class io.grpc.services.MetricRecorder
-
Update the memory utilization metrics data in the range [0, 1].
- setMessage(Message) - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
Used by EVENT_TYPE_CLIENT_MESSAGE, EVENT_TYPE_SERVER_MESSAGE
- setMessage(Message.Builder) - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
Used by EVENT_TYPE_CLIENT_MESSAGE, EVENT_TYPE_SERVER_MESSAGE
- 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.inprocess.InProcessTransport.InProcessStream.InProcessClientStream
- setMessageCompression(boolean) - Method in class io.grpc.inprocess.InProcessTransport.InProcessStream.InProcessServerStream
- setMessageCompression(boolean) - Method in class io.grpc.internal.AbstractClientStream.GetFramer
- setMessageCompression(boolean) - Method in class io.grpc.internal.AbstractStream
- setMessageCompression(boolean) - Method in class io.grpc.internal.ClientCallImpl
- setMessageCompression(boolean) - Method in class io.grpc.internal.DelayedClientCall
- setMessageCompression(boolean) - Method in class io.grpc.internal.DelayedStream
- setMessageCompression(boolean) - Method in class io.grpc.internal.ForwardingClientStream
- 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 class io.grpc.internal.RetriableStream
- setMessageCompression(boolean) - Method in class io.grpc.internal.ServerCallImpl
- 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.PartialForwardingClientCall
- setMessageCompression(boolean) - Method in class io.grpc.PartialForwardingServerCall
- setMessageCompression(boolean) - Method in class io.grpc.ServerCall
-
Enables per-message compression, if an encoding type has been negotiated.
- setMessageCompression(boolean) - Method in class io.grpc.stub.CallStreamObserver
-
Sets message compression for subsequent calls to
StreamObserver.onNext(V)
. - setMessageCompression(boolean) - Method in class io.grpc.stub.ClientCalls.CallToStreamObserverAdapter
- setMessageCompression(boolean) - Method in class io.grpc.stub.ClientCallStreamObserver
-
Sets message compression for subsequent calls to
StreamObserver.onNext(V)
. - setMessageCompression(boolean) - Method in class io.grpc.stub.ServerCalls.ServerCallStreamObserverImpl
- setMessageCompression(boolean) - Method in class io.grpc.stub.ServerCallStreamObserver
-
Sets message compression for subsequent calls to
StreamObserver.onNext(V)
. - setMessageCompression(boolean) - Method in class io.grpc.util.TransmitStatusRuntimeExceptionInterceptor.SerializingServerCall
- setMessagesReceived(long) - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The number of grpc messages received on this socket.
- setMessagesSent(long) - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The number of grpc messages successfully sent on this socket.
- setMetadata(Metadata) - Method in class io.grpc.binarylog.v1.ClientHeader.Builder
-
This contains only the metadata from the application.
- setMetadata(Metadata) - Method in class io.grpc.binarylog.v1.ServerHeader.Builder
-
This contains only the metadata from the application.
- setMetadata(Metadata) - Method in class io.grpc.binarylog.v1.Trailer.Builder
-
This contains only the metadata from the application.
- setMetadata(Metadata.Builder) - Method in class io.grpc.binarylog.v1.ClientHeader.Builder
-
This contains only the metadata from the application.
- setMetadata(Metadata.Builder) - Method in class io.grpc.binarylog.v1.ServerHeader.Builder
-
This contains only the metadata from the application.
- setMetadata(Metadata.Builder) - Method in class io.grpc.binarylog.v1.Trailer.Builder
-
This contains only the metadata from the application.
- setMethod(String) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys.Builder
-
string method = 3;
- setMethod(String) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Name.Builder
-
string method = 2;
- setMethodBytes(ByteString) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys.Builder
-
string method = 3;
- setMethodBytes(ByteString) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Name.Builder
-
string method = 2;
- setMethodName(String) - Method in class io.grpc.binarylog.v1.ClientHeader.Builder
-
The name of the RPC method, which looks something like: /<service>/<method> Note the leading "/" character.
- setMethodNameBytes(ByteString) - Method in class io.grpc.binarylog.v1.ClientHeader.Builder
-
The name of the RPC method, which looks something like: /<service>/<method> Note the leading "/" character.
- setMinimumHosts(Integer) - Method in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig.FailurePercentageEjection.Builder
-
The minimum amount of host for failure percentage ejection to be enabled.
- setMinimumHosts(Integer) - Method in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig.SuccessRateEjection.Builder
-
The minimum amount of hosts needed for success rate ejection.
- setMultiplier(double) - Method in class io.grpc.internal.ExponentialBackoffPolicy
- setName(String) - Method in class io.grpc.channelz.v1.Address.OtherAddress.Builder
-
The human readable version of the value.
- setName(String) - Method in class io.grpc.channelz.v1.ChannelRef.Builder
-
An optional name associated with the channel.
- setName(String) - Method in class io.grpc.channelz.v1.Security.OtherSecurity.Builder
-
The human readable version of the value.
- setName(String) - Method in class io.grpc.channelz.v1.ServerRef.Builder
-
An optional name associated with the server.
- setName(String) - Method in class io.grpc.channelz.v1.SocketOption.Builder
-
The full name of the socket option.
- setName(String) - Method in class io.grpc.channelz.v1.SocketRef.Builder
-
An optional name associated with the socket.
- setName(String) - Method in class io.grpc.channelz.v1.SubchannelRef.Builder
-
An optional name associated with the subchannel.
- setName(String) - Method in class io.grpc.lb.v1.InitialLoadBalanceRequest.Builder
-
The name of the load balanced service (e.g., service.googleapis.com).
- setName(String) - Method in class io.grpc.reflection.v1.ServiceResponse.Builder
-
Full name of a registered service, including its package name.
- setName(String) - Method in class io.grpc.reflection.v1alpha.ServiceResponse.Builder
-
Full name of a registered service, including its package name.
- setName(String) - Method in class io.grpc.ServiceDescriptor.Builder
-
Sets the name.
- setNameBytes(ByteString) - Method in class io.grpc.channelz.v1.Address.OtherAddress.Builder
-
The human readable version of the value.
- setNameBytes(ByteString) - Method in class io.grpc.channelz.v1.ChannelRef.Builder
-
An optional name associated with the channel.
- setNameBytes(ByteString) - Method in class io.grpc.channelz.v1.Security.OtherSecurity.Builder
-
The human readable version of the value.
- setNameBytes(ByteString) - Method in class io.grpc.channelz.v1.ServerRef.Builder
-
An optional name associated with the server.
- setNameBytes(ByteString) - Method in class io.grpc.channelz.v1.SocketOption.Builder
-
The full name of the socket option.
- setNameBytes(ByteString) - Method in class io.grpc.channelz.v1.SocketRef.Builder
-
An optional name associated with the socket.
- setNameBytes(ByteString) - Method in class io.grpc.channelz.v1.SubchannelRef.Builder
-
An optional name associated with the subchannel.
- setNameBytes(ByteString) - Method in class io.grpc.lb.v1.InitialLoadBalanceRequest.Builder
-
The name of the load balanced service (e.g., service.googleapis.com).
- setNameBytes(ByteString) - Method in class io.grpc.reflection.v1.ServiceResponse.Builder
-
Full name of a registered service, including its package name.
- setNameBytes(ByteString) - Method in class io.grpc.reflection.v1alpha.ServiceResponse.Builder
-
Full name of a registered service, including its package name.
- setNames(int, GrpcKeyBuilder.Name) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
-
repeated .grpc.lookup.v1.GrpcKeyBuilder.Name names = 1;
- setNames(int, GrpcKeyBuilder.Name.Builder) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Builder
-
repeated .grpc.lookup.v1.GrpcKeyBuilder.Name names = 1;
- setNames(int, String) - Method in class io.grpc.lookup.v1.NameMatcher.Builder
-
Ordered list of names (headers or query parameter names) that can supply this value; the first one with a non-empty value is used.
- setNonExistent() - Method in class io.grpc.netty.NettyClientStream.TransportState
-
Marks the stream state as if it had never existed.
- setNumCalls(long) - Method in class io.grpc.lb.v1.ClientStatsPerToken.Builder
-
The total number of RPCs that finished associated with the token.
- setNumCallsFinished(long) - Method in class io.grpc.lb.v1.ClientStats.Builder
-
The total number of RPCs that finished.
- setNumCallsFinishedKnownReceived(long) - Method in class io.grpc.lb.v1.ClientStats.Builder
-
The total number of RPCs that finished and are known to have been received by a server.
- setNumCallsFinishedWithClientFailedToSend(long) - Method in class io.grpc.lb.v1.ClientStats.Builder
-
The total number of RPCs that failed to reach a server except dropped RPCs.
- setNumCallsStarted(long) - Method in class io.grpc.lb.v1.ClientStats.Builder
-
The total number of RPCs that started.
- setNumEventsLogged(long) - Method in class io.grpc.channelz.v1.ChannelTrace.Builder
-
Number of events ever logged in this tracing object.
- setNumEventsLogged(long) - Method in class io.grpc.InternalChannelz.ChannelTrace.Builder
- setObject(CharSequence, Iterable<?>) - Method in class io.grpc.netty.AbstractHttp2Headers
- setObject(CharSequence, Object) - Method in class io.grpc.netty.AbstractHttp2Headers
- setObject(CharSequence, Object...) - Method in class io.grpc.netty.AbstractHttp2Headers
- setOffloadExecutor(Executor) - Method in class io.grpc.NameResolver.Args.Builder
- setOnCancelHandler(Runnable) - Method in class io.grpc.stub.ServerCalls.ServerCallStreamObserverImpl
- setOnCancelHandler(Runnable) - Method in class io.grpc.stub.ServerCallStreamObserver
-
Sets a
Runnable
to be called if the call is cancelled and the server is encouraged to abort processing to save resources, since the client will not process any further messages. - setOnCloseHandler(Runnable) - Method in class io.grpc.stub.ServerCalls.ServerCallStreamObserverImpl
- setOnCloseHandler(Runnable) - Method in class io.grpc.stub.ServerCallStreamObserver
-
Sets a
Runnable
to be executed when the call is closed cleanly from the server's point of view: eitherStreamObserver.onCompleted()
orStreamObserver.onError(Throwable)
has been called, all the messages and trailing metadata have been sent and the stream has been closed. - setOnReadyHandler(Runnable) - Method in class io.grpc.stub.CallStreamObserver
-
Set a
Runnable
that will be executed every time the streamCallStreamObserver.isReady()
state changes fromfalse
totrue
. - setOnReadyHandler(Runnable) - Method in class io.grpc.stub.ClientCalls.CallToStreamObserverAdapter
- setOnReadyHandler(Runnable) - Method in class io.grpc.stub.ClientCallStreamObserver
-
Set a
Runnable
that will be executed every time the streamClientCallStreamObserver.isReady()
state changes fromfalse
totrue
. - setOnReadyHandler(Runnable) - Method in class io.grpc.stub.ServerCalls.ServerCallStreamObserverImpl
- setOnReadyHandler(Runnable) - Method in class io.grpc.stub.ServerCallStreamObserver
-
Set a
Runnable
that will be executed every time the streamServerCallStreamObserver.isReady()
state changes fromfalse
totrue
. - setOnReadyThreshold(int) - Method in class io.grpc.inprocess.InProcessTransport.InProcessStream.InProcessServerStream
- setOnReadyThreshold(int) - Method in class io.grpc.internal.AbstractServerStream
-
A hint to the stream that specifies how many bytes must be queued before
AbstractServerStream.isReady()
will return false. - setOnReadyThreshold(int) - Method in class io.grpc.internal.AbstractStream
-
A hint to the stream that specifies how many bytes must be queued before
AbstractStream.isReady()
will return false. - setOnReadyThreshold(int) - Method in class io.grpc.internal.AbstractStream.TransportState
-
A hint to the stream that specifies how many bytes must be queued before
AbstractStream.TransportState.isReady()
will return false. - setOnReadyThreshold(int) - Method in class io.grpc.internal.ServerCallImpl
- setOnReadyThreshold(int) - Method in interface io.grpc.internal.ServerStream
-
A hint to the stream that specifies how many bytes must be queued before
Stream.isReady()
will return false. - setOnReadyThreshold(int) - Method in class io.grpc.PartialForwardingServerCall
- setOnReadyThreshold(int) - Method in class io.grpc.ServerCall
-
A hint to the call that specifies how many bytes must be queued before
ServerCall.isReady()
will return false. - setOnReadyThreshold(int) - Method in class io.grpc.stub.ServerCalls.ServerCallStreamObserverImpl
- setOnReadyThreshold(int) - Method in class io.grpc.stub.ServerCallStreamObserver
-
A hint to the call that specifies how many bytes must be queued before
ServerCallStreamObserver.isReady()
will return false. - setOnReadyThreshold(int) - Method in class io.grpc.util.TransmitStatusRuntimeExceptionInterceptor.SerializingServerCall
- setOption(int, SocketOption) - Method in class io.grpc.channelz.v1.SocketData.Builder
-
Socket options set on this socket.
- setOption(int, SocketOption.Builder) - Method in class io.grpc.channelz.v1.SocketData.Builder
-
Socket options set on this socket.
- setOptions(int) - Method in class io.grpc.InternalChannelz.TcpInfo.Builder
- setOriginalRequest(ServerReflectionRequest) - Method in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
-
.grpc.reflection.v1.ServerReflectionRequest original_request = 2;
- setOriginalRequest(ServerReflectionRequest.Builder) - Method in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
-
.grpc.reflection.v1.ServerReflectionRequest original_request = 2;
- setOriginalRequest(ServerReflectionRequest) - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
-
.grpc.reflection.v1alpha.ServerReflectionRequest original_request = 2;
- setOriginalRequest(ServerReflectionRequest.Builder) - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
-
.grpc.reflection.v1alpha.ServerReflectionRequest original_request = 2;
- setOther(Security.OtherSecurity) - Method in class io.grpc.channelz.v1.Security.Builder
-
.grpc.channelz.v1.Security.OtherSecurity other = 2;
- setOther(Security.OtherSecurity.Builder) - Method in class io.grpc.channelz.v1.Security.Builder
-
.grpc.channelz.v1.Security.OtherSecurity other = 2;
- setOtherAddress(Address.OtherAddress) - Method in class io.grpc.channelz.v1.Address.Builder
-
.grpc.channelz.v1.Address.OtherAddress other_address = 3;
- setOtherAddress(Address.OtherAddress.Builder) - Method in class io.grpc.channelz.v1.Address.Builder
-
.grpc.channelz.v1.Address.OtherAddress other_address = 3;
- setOtherName(String) - Method in class io.grpc.channelz.v1.Security.Tls.Builder
-
Some other way to describe the cipher suite if the RFC 4346 name is not available.
- setOtherNameBytes(ByteString) - Method in class io.grpc.channelz.v1.Security.Tls.Builder
-
Some other way to describe the cipher suite if the RFC 4346 name is not available.
- setOutboundClosed() - Method in class io.grpc.internal.AbstractClientStream.TransportState
- setOverrideAuthority(String) - Method in class io.grpc.NameResolver.Args.Builder
- setPassword(String) - Method in class io.grpc.HttpConnectProxiedSocketAddress.Builder
-
Sets the password used to connect to the proxy.
- setPathPatterns(int, String) - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
-
path_pattern is an ordered list of path template patterns for the desired value.
- setPayloadTruncated(boolean) - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
true if payload does not represent the full message or metadata.
- setPeer(Address) - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
Peer address information, will only be recorded on the first incoming event.
- setPeer(Address.Builder) - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
Peer address information, will only be recorded on the first incoming event.
- setPinging(boolean) - Method in class io.grpc.netty.AbstractNettyHandler.FlowControlPinger
- setPmtu(int) - Method in class io.grpc.InternalChannelz.TcpInfo.Builder
- setPort(int) - Method in class io.grpc.channelz.v1.Address.TcpIpAddress.Builder
-
0-64k, or -1 if not appropriate.
- setPort(int) - Method in class io.grpc.lb.v1.Server.Builder
-
A resolved port number for the server.
- setPreviousAttempts(int) - Method in class io.grpc.ClientStreamTracer.StreamInfo.Builder
-
Set the number of preceding attempts of the RPC.
- setProbes(int) - Method in class io.grpc.InternalChannelz.TcpInfo.Builder
- setProtocolNegotiatorFactory(NettyChannelBuilder, InternalNettyChannelBuilder.ProtocolNegotiatorFactory) - Static method in class io.grpc.netty.InternalNettyChannelBuilder
-
Sets the
InternalNettyChannelBuilder.ProtocolNegotiatorFactory
to be used. - setProtocolNegotiatorFactory(NettyChannelBuilder, InternalProtocolNegotiator.ClientFactory) - Static method in class io.grpc.netty.InternalNettyChannelBuilder
-
Sets the
InternalNettyChannelBuilder.ProtocolNegotiatorFactory
to be used. - setProxyAddress(SocketAddress) - Method in class io.grpc.HttpConnectProxiedSocketAddress.Builder
-
Sets the address to the proxy, which is already resolved.
- setProxyDetector(ProxyDetector) - Method in class io.grpc.NameResolver.Args.Builder
- setPseudoHeader(AsciiString, AsciiString) - Method in class io.grpc.netty.GrpcHttp2HeadersUtils.GrpcHttp2RequestHeaders
- setQpsMetric(double) - Method in class io.grpc.services.MetricRecorder
-
Update the QPS metrics data in the range [0, inf).
- setQueryParameters(int, NameMatcher) - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
-
List of query parameter names to try to match.
- setQueryParameters(int, NameMatcher.Builder) - Method in class io.grpc.lookup.v1.HttpKeyBuilder.Builder
-
List of query parameter names to try to match.
- setRandom(Random) - Method in class io.grpc.internal.ExponentialBackoffPolicy
- setRandom(Random) - Static method in class io.grpc.internal.RetriableStream
- setRatioForAccepts(float) - Method in class io.grpc.rls.AdaptiveThrottler.Builder
- setRawMethodName(int, Object) - Method in class io.grpc.MethodDescriptor
-
Safely, but weakly, sets the raw method name for this Method Descriptor.
- 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
- setRealCall(ClientCall<ReqT, RespT>) - Method in class io.grpc.internal.DelayedClientCall
- setRealStream(ClientStream) - Method in class io.grpc.internal.DelayedStream
- setReason(RouteLookupRequest.Reason) - Method in class io.grpc.lookup.v1.RouteLookupRequest.Builder
-
Reason for making this request.
- setReasonValue(int) - Method in class io.grpc.lookup.v1.RouteLookupRequest.Builder
-
Reason for making this request.
- setRef(ChannelRef) - Method in class io.grpc.channelz.v1.Channel.Builder
-
The identifier for this channel.
- setRef(ChannelRef.Builder) - Method in class io.grpc.channelz.v1.Channel.Builder
-
The identifier for this channel.
- setRef(ServerRef) - Method in class io.grpc.channelz.v1.Server.Builder
-
The identifier for a Server.
- setRef(ServerRef.Builder) - Method in class io.grpc.channelz.v1.Server.Builder
-
The identifier for a Server.
- setRef(SocketRef) - Method in class io.grpc.channelz.v1.Socket.Builder
-
The identifier for the Socket.
- setRef(SocketRef.Builder) - Method in class io.grpc.channelz.v1.Socket.Builder
-
The identifier for the Socket.
- setRef(SubchannelRef) - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
The identifier for this channel.
- setRef(SubchannelRef.Builder) - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
The identifier for this channel.
- setRemote(Address) - Method in class io.grpc.channelz.v1.Socket.Builder
-
The remote bound address.
- setRemote(Address.Builder) - Method in class io.grpc.channelz.v1.Socket.Builder
-
The remote bound address.
- setRemoteCertificate(ByteString) - Method in class io.grpc.channelz.v1.Security.Tls.Builder
-
the certificate used by the remote endpoint.
- setRemoteFlowControlWindow(Int64Value) - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The amount of window, granted to the remote endpoint by the local endpoint.
- setRemoteFlowControlWindow(Int64Value.Builder) - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The amount of window, granted to the remote endpoint by the local endpoint.
- setRemoteName(String) - Method in class io.grpc.channelz.v1.Socket.Builder
-
Optional, represents the name of the remote endpoint, if different than the original target name.
- setRemoteNameBytes(ByteString) - Method in class io.grpc.channelz.v1.Socket.Builder
-
Optional, represents the name of the remote endpoint, if different than the original target name.
- 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.
- setRequestsPadding(int) - Method in class io.grpc.rls.AdaptiveThrottler.Builder
- setRequestVolume(Integer) - Method in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig.FailurePercentageEjection.Builder
-
The request volume required for an address to be considered for failure percentage ejection.
- setRequestVolume(Integer) - Method in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig.SuccessRateEjection.Builder
-
The minimum address request volume to be considered for success rate ejection.
- setRequiredMatch(boolean) - Method in class io.grpc.lookup.v1.NameMatcher.Builder
-
If true, make this extraction required; the key builder will not match if no value is found.
- setResolvedAddresses(LoadBalancer.ResolvedAddresses) - Method in class io.grpc.util.MultiChildLoadBalancer.ChildLbState
- setResolvedAddressesFactory(ResolvedAddressFactory) - Method in class io.grpc.rls.CachingRlsLbClient.Builder
-
Sets a factory to create
LoadBalancer.ResolvedAddresses
for child load balancer. - setResourceResolver(DnsNameResolver.ResourceResolver) - Method in class io.grpc.grpclb.GrpclbNameResolver
- setResourceResolver(DnsNameResolver.ResourceResolver) - Method in class io.grpc.internal.DnsNameResolver
- 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
- setRouteLookupConfig(RouteLookupConfig) - Method in class io.grpc.lookup.v1.RouteLookupClusterSpecifier.Builder
-
The RLS config for this cluster specifier plugin instance.
- setRouteLookupConfig(RouteLookupConfig.Builder) - Method in class io.grpc.lookup.v1.RouteLookupClusterSpecifier.Builder
-
The RLS config for this cluster specifier plugin instance.
- 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.
- setScheduledExecutorService(ScheduledExecutorService) - Method in class io.grpc.NameResolver.Args.Builder
- 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.
- setSecurity(Security) - Method in class io.grpc.channelz.v1.Socket.Builder
-
Security details for this socket.
- setSecurity(Security.Builder) - Method in class io.grpc.channelz.v1.Socket.Builder
-
Security details for this socket.
- setSequenceIdWithinCall(long) - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
The entry sequence id for this call.
- setServer(int, Server) - Method in class io.grpc.channelz.v1.GetServersResponse.Builder
-
list of servers that the connection detail service knows about.
- setServer(int, Server.Builder) - Method in class io.grpc.channelz.v1.GetServersResponse.Builder
-
list of servers that the connection detail service knows about.
- setServer(Server) - Method in class io.grpc.channelz.v1.GetServerResponse.Builder
-
The Server that corresponds to the requested server_id.
- setServer(Server.Builder) - Method in class io.grpc.channelz.v1.GetServerResponse.Builder
-
The Server that corresponds to the requested server_id.
- setServer(InProcessServer) - Method in class io.grpc.inprocess.AnonymousInProcessSocketAddress
- setServerHeader(ServerHeader) - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
.grpc.binarylog.v1.ServerHeader server_header = 7;
- setServerHeader(ServerHeader.Builder) - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
.grpc.binarylog.v1.ServerHeader server_header = 7;
- setServerId(long) - Method in class io.grpc.channelz.v1.GetServerRequest.Builder
-
server_id is the identifier of the specific server to get.
- setServerId(long) - Method in class io.grpc.channelz.v1.GetServerSocketsRequest.Builder
-
int64 server_id = 1;
- setServerId(long) - Method in class io.grpc.channelz.v1.ServerRef.Builder
-
A globally unique identifier for this server.
- setServerList(ServerList) - Method in class io.grpc.lb.v1.LoadBalanceResponse.Builder
-
Contains the list of servers selected by the load balancer.
- setServerList(ServerList.Builder) - Method in class io.grpc.lb.v1.LoadBalanceResponse.Builder
-
Contains the list of servers selected by the load balancer.
- setServers(int, Server) - Method in class io.grpc.lb.v1.ServerList.Builder
-
Contains a list of servers selected by the load balancer.
- setServers(int, Server.Builder) - Method in class io.grpc.lb.v1.ServerList.Builder
-
Contains a list of servers selected by the load balancer.
- setService(int, ServiceResponse) - Method in class io.grpc.reflection.v1.ListServiceResponse.Builder
-
The information of each service may be expanded in the future, so we use ServiceResponse message to encapsulate it.
- setService(int, ServiceResponse.Builder) - Method in class io.grpc.reflection.v1.ListServiceResponse.Builder
-
The information of each service may be expanded in the future, so we use ServiceResponse message to encapsulate it.
- setService(int, ServiceResponse) - Method in class io.grpc.reflection.v1alpha.ListServiceResponse.Builder
-
The information of each service may be expanded in the future, so we use ServiceResponse message to encapsulate it.
- setService(int, ServiceResponse.Builder) - Method in class io.grpc.reflection.v1alpha.ListServiceResponse.Builder
-
The information of each service may be expanded in the future, so we use ServiceResponse message to encapsulate it.
- setService(String) - Method in class io.grpc.health.v1.HealthCheckRequest.Builder
-
string service = 1;
- setService(String) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys.Builder
-
string service = 2;
- setService(String) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Name.Builder
-
string service = 1;
- setServiceBytes(ByteString) - Method in class io.grpc.health.v1.HealthCheckRequest.Builder
-
string service = 1;
- setServiceBytes(ByteString) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys.Builder
-
string service = 2;
- setServiceBytes(ByteString) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Name.Builder
-
string service = 1;
- setServiceConfig(NameResolver.ConfigOrError) - Method in class io.grpc.NameResolver.ResolutionResult.Builder
-
Sets the Service Config parsed by
NameResolver.Args.getServiceConfigParser()
. - setServiceConfigParser(NameResolver.ServiceConfigParser) - Method in class io.grpc.NameResolver.Args.Builder
- setServiceName(String) - Method in class io.grpc.protobuf.services.HealthCheckingLoadBalancerFactory.HealthCheckState
- setSeverity(ChannelTraceEvent.Severity) - Method in class io.grpc.channelz.v1.ChannelTraceEvent.Builder
-
the severity of the trace event
- setSeverity(InternalChannelz.ChannelTrace.Event.Severity) - Method in class io.grpc.InternalChannelz.ChannelTrace.Event.Builder
- setSeverityValue(int) - Method in class io.grpc.channelz.v1.ChannelTraceEvent.Builder
-
the severity of the trace event
- setShort(CharSequence, short) - Method in class io.grpc.netty.AbstractHttp2Headers
- 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
- setSocket(Socket) - Method in class io.grpc.channelz.v1.GetSocketResponse.Builder
-
The Socket that corresponds to the requested socket_id.
- setSocket(Socket.Builder) - Method in class io.grpc.channelz.v1.GetSocketResponse.Builder
-
The Socket that corresponds to the requested socket_id.
- setSocketId(long) - Method in class io.grpc.channelz.v1.GetSocketRequest.Builder
-
socket_id is the identifier of the specific socket to get.
- setSocketId(long) - Method in class io.grpc.channelz.v1.SocketRef.Builder
-
The globally unique id for this socket.
- setSocketOptionLingerSeconds(Integer) - Method in class io.grpc.InternalChannelz.SocketOptions.Builder
-
The value of
Socket.getSoLinger()
. - setSocketOptionTimeoutMillis(Integer) - Method in class io.grpc.InternalChannelz.SocketOptions.Builder
-
The value of
Socket.getSoTimeout()
. - setSocketRef(int, SocketRef) - Method in class io.grpc.channelz.v1.Channel.Builder
-
There are no ordering guarantees on the order of sockets.
- setSocketRef(int, SocketRef) - Method in class io.grpc.channelz.v1.GetServerSocketsResponse.Builder
-
list of socket refs that the connection detail service knows about.
- setSocketRef(int, SocketRef) - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
There are no ordering guarantees on the order of sockets.
- setSocketRef(int, SocketRef.Builder) - Method in class io.grpc.channelz.v1.Channel.Builder
-
There are no ordering guarantees on the order of sockets.
- setSocketRef(int, SocketRef.Builder) - Method in class io.grpc.channelz.v1.GetServerSocketsResponse.Builder
-
list of socket refs that the connection detail service knows about.
- setSocketRef(int, SocketRef.Builder) - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
There are no ordering guarantees on the order of sockets.
- setSockets(List<InternalWithLogId>) - Method in class io.grpc.InternalChannelz.ChannelStats.Builder
-
Sets the sockets.
- setSslSocketAndEnginePeerVerifier(AdvancedTlsX509TrustManager.SslSocketAndEnginePeerVerifier) - Method in class io.grpc.util.AdvancedTlsX509TrustManager.Builder
-
Sets
AdvancedTlsX509TrustManager.SslSocketAndEnginePeerVerifier
, which methods will be called in addition to verifying certificates. - setStaleAge(Duration) - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
After a response has been in the client cache for this amount of time and is re-requested, start an asynchronous RPC to re-validate it.
- setStaleAge(Duration.Builder) - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
After a response has been in the client cache for this amount of time and is re-requested, start an asynchronous RPC to re-validate it.
- setStaleHeaderData(String) - Method in class io.grpc.lookup.v1.RouteLookupRequest.Builder
-
For REASON_STALE, the header_data from the stale response, if any.
- setStaleHeaderDataBytes(ByteString) - Method in class io.grpc.lookup.v1.RouteLookupRequest.Builder
-
For REASON_STALE, the header_data from the stale response, if any.
- setStandardName(String) - Method in class io.grpc.channelz.v1.Security.Tls.Builder
-
The cipher suite name in the RFC 4346 format: https://tools.ietf.org/html/rfc4346#appendix-C
- setStandardNameBytes(ByteString) - Method in class io.grpc.channelz.v1.Security.Tls.Builder
-
The cipher suite name in the RFC 4346 format: https://tools.ietf.org/html/rfc4346#appendix-C
- setStartChannelId(long) - Method in class io.grpc.channelz.v1.GetTopChannelsRequest.Builder
-
start_channel_id indicates that only channels at or above this id should be included in the results.
- setStartServerId(long) - Method in class io.grpc.channelz.v1.GetServersRequest.Builder
-
start_server_id indicates that only servers at or above this id should be included in the results.
- setStartSocketId(long) - Method in class io.grpc.channelz.v1.GetServerSocketsRequest.Builder
-
start_socket_id indicates that only sockets at or above this id should be included in the results.
- setState(int) - Method in class io.grpc.InternalChannelz.TcpInfo.Builder
- setState(ChannelConnectivityState) - Method in class io.grpc.channelz.v1.ChannelData.Builder
-
The connectivity state of the channel or subchannel.
- setState(ChannelConnectivityState.Builder) - Method in class io.grpc.channelz.v1.ChannelData.Builder
-
The connectivity state of the channel or subchannel.
- setState(ChannelConnectivityState.State) - Method in class io.grpc.channelz.v1.ChannelConnectivityState.Builder
-
.grpc.channelz.v1.ChannelConnectivityState.State state = 1;
- setState(ConnectivityState) - Method in class io.grpc.InternalChannelz.ChannelStats.Builder
- setStateValue(int) - Method in class io.grpc.channelz.v1.ChannelConnectivityState.Builder
-
.grpc.channelz.v1.ChannelConnectivityState.State state = 1;
- setStatsEnabled(boolean) - Method in class io.grpc.inprocess.InProcessChannelBuilder
- setStatsEnabled(boolean) - Method in class io.grpc.inprocess.InProcessServerBuilder
- setStatsEnabled(boolean) - Method in class io.grpc.internal.ManagedChannelImplBuilder
-
Disable or enable stats features.
- setStatsEnabled(boolean) - Method in class io.grpc.internal.ServerImplBuilder
-
Disable or enable stats features.
- setStatsEnabled(boolean) - Method in class io.grpc.netty.NettyChannelBuilder
- setStatsEnabled(boolean) - Method in class io.grpc.netty.NettyServerBuilder
- setStatsEnabled(InProcessChannelBuilder, boolean) - Static method in class io.grpc.inprocess.InternalInProcessChannelBuilder
- setStatsEnabled(InProcessServerBuilder, boolean) - Static method in class io.grpc.inprocess.InternalInProcessServerBuilder
- setStatsEnabled(NettyChannelBuilder, boolean) - Static method in class io.grpc.netty.InternalNettyChannelBuilder
- setStatsEnabled(NettyServerBuilder, boolean) - Static method in class io.grpc.netty.InternalNettyServerBuilder
- setStatsRecordFinishedRpcs(boolean) - Method in class io.grpc.internal.ManagedChannelImplBuilder
-
Disable or enable stats recording for RPC completions.
- setStatsRecordFinishedRpcs(boolean) - Method in class io.grpc.internal.ServerImplBuilder
-
Disable or enable stats recording for RPC completions.
- setStatsRecordFinishedRpcs(boolean) - Method in class io.grpc.netty.NettyChannelBuilder
- setStatsRecordFinishedRpcs(NettyChannelBuilder, boolean) - Static method in class io.grpc.netty.InternalNettyChannelBuilder
- setStatsRecordRealTimeMetrics(boolean) - Method in class io.grpc.internal.ManagedChannelImplBuilder
-
Disable or enable real-time metrics recording.
- setStatsRecordRealTimeMetrics(boolean) - Method in class io.grpc.internal.ServerImplBuilder
-
Disable or enable real-time metrics recording.
- setStatsRecordRealTimeMetrics(boolean) - Method in class io.grpc.netty.NettyChannelBuilder
- setStatsRecordRealTimeMetrics(boolean) - Method in class io.grpc.netty.NettyServerBuilder
- setStatsRecordRealTimeMetrics(NettyChannelBuilder, boolean) - Static method in class io.grpc.netty.InternalNettyChannelBuilder
- setStatsRecordRealTimeMetrics(NettyServerBuilder, boolean) - Static method in class io.grpc.netty.InternalNettyServerBuilder
- setStatsRecordRetryMetrics(boolean) - Method in class io.grpc.internal.ManagedChannelImplBuilder
- setStatsRecordRetryMetrics(boolean) - Method in class io.grpc.netty.NettyChannelBuilder
- setStatsRecordRetryMetrics(NettyChannelBuilder, boolean) - Static method in class io.grpc.netty.InternalNettyChannelBuilder
- setStatsRecordStartedRpcs(boolean) - Method in class io.grpc.internal.ManagedChannelImplBuilder
-
Disable or enable stats recording for RPC upstarts.
- setStatsRecordStartedRpcs(boolean) - Method in class io.grpc.internal.ServerImplBuilder
-
Disable or enable stats recording for RPC upstarts.
- setStatsRecordStartedRpcs(boolean) - Method in class io.grpc.netty.NettyChannelBuilder
- setStatsRecordStartedRpcs(boolean) - Method in class io.grpc.netty.NettyServerBuilder
- setStatsRecordStartedRpcs(NettyChannelBuilder, boolean) - Static method in class io.grpc.netty.InternalNettyChannelBuilder
- setStatsRecordStartedRpcs(NettyServerBuilder, boolean) - Static method in class io.grpc.netty.InternalNettyServerBuilder
- setStatus(HealthCheckResponse.ServingStatus) - Method in class io.grpc.health.v1.HealthCheckResponse.Builder
-
.grpc.health.v1.HealthCheckResponse.ServingStatus status = 1;
- setStatus(String, HealthCheckResponse.ServingStatus) - Method in class io.grpc.protobuf.services.HealthServiceImpl
- setStatus(String, HealthCheckResponse.ServingStatus) - Method in class io.grpc.protobuf.services.HealthStatusManager
-
Updates the status of the server.
- setStatus(String, HealthCheckResponse.ServingStatus) - Method in class io.grpc.services.HealthStatusManager
-
Deprecated.Updates the status of the server.
- setStatusCode(int) - Method in class io.grpc.binarylog.v1.Trailer.Builder
-
The gRPC status code.
- setStatusDetails(ByteString) - Method in class io.grpc.binarylog.v1.Trailer.Builder
-
The value of the 'grpc-status-details-bin' metadata key.
- setStatusInternal(String, HealthCheckResponse.ServingStatus) - Method in class io.grpc.protobuf.services.HealthServiceImpl
- setStatusMessage(String) - Method in class io.grpc.binarylog.v1.Trailer.Builder
-
An original status message before any transport specific encoding.
- setStatusMessageBytes(ByteString) - Method in class io.grpc.binarylog.v1.Trailer.Builder
-
An original status message before any transport specific encoding.
- setStatusValue(int) - Method in class io.grpc.health.v1.HealthCheckResponse.Builder
-
.grpc.health.v1.HealthCheckResponse.ServingStatus status = 1;
- setStdevFactor(Integer) - Method in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig.SuccessRateEjection.Builder
-
The product of this and the standard deviation of success rates determine the ejection threshold.
- setStream(ClientStream) - Method in class io.grpc.internal.DelayedStream
-
Transfers all pending and future requests and mutations to the given stream.
- setStreamsFailed(long) - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The number of streams that have ended unsuccessfully: On client side, ended without receiving frame with eos bit set; On server side, ended without sending frame with eos bit set.
- setStreamsStarted(long) - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The number of streams that have been started.
- setStreamsSucceeded(long) - Method in class io.grpc.channelz.v1.SocketData.Builder
-
The number of streams that have ended successfully: On client side, received frame with eos bit set; On server side, sent frame with eos bit set.
- setStubType(CallOptions, InternalClientCalls.StubType) - Static method in class io.grpc.stub.InternalClientCalls
-
Returns
CallOptions
with the correspondingClientCalls.StubType
set. - setSubchannel(Subchannel) - Method in class io.grpc.channelz.v1.GetSubchannelResponse.Builder
-
The Subchannel that corresponds to the requested subchannel_id.
- setSubchannel(Subchannel.Builder) - Method in class io.grpc.channelz.v1.GetSubchannelResponse.Builder
-
The Subchannel that corresponds to the requested subchannel_id.
- setSubchannel(InternalSubchannel) - Method in class io.grpc.internal.OobChannel
- setSubchannel(LoadBalancer.Subchannel) - Method in class io.grpc.protobuf.services.HealthCheckingLoadBalancerFactory.HealthCheckState
- setSubchannelId(long) - Method in class io.grpc.channelz.v1.GetSubchannelRequest.Builder
-
subchannel_id is the identifier of the specific subchannel to get.
- setSubchannelId(long) - Method in class io.grpc.channelz.v1.SubchannelRef.Builder
-
The globally unique id for this subchannel.
- setSubchannelRef(int, SubchannelRef) - Method in class io.grpc.channelz.v1.Channel.Builder
-
At most one of 'channel_ref+subchannel_ref' and 'socket' is set.
- setSubchannelRef(int, SubchannelRef) - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
At most one of 'channel_ref+subchannel_ref' and 'socket' is set.
- setSubchannelRef(int, SubchannelRef.Builder) - Method in class io.grpc.channelz.v1.Channel.Builder
-
At most one of 'channel_ref+subchannel_ref' and 'socket' is set.
- setSubchannelRef(int, SubchannelRef.Builder) - Method in class io.grpc.channelz.v1.Subchannel.Builder
-
At most one of 'channel_ref+subchannel_ref' and 'socket' is set.
- setSubchannelRef(SubchannelRef) - Method in class io.grpc.channelz.v1.ChannelTraceEvent.Builder
-
.grpc.channelz.v1.SubchannelRef subchannel_ref = 5;
- setSubchannelRef(SubchannelRef.Builder) - Method in class io.grpc.channelz.v1.ChannelTraceEvent.Builder
-
.grpc.channelz.v1.SubchannelRef subchannel_ref = 5;
- 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.
- setSuccessRateEjection(OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig.SuccessRateEjection) - Method in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig.Builder
-
Set to enable success rate ejection.
- setSummary(boolean) - Method in class io.grpc.channelz.v1.GetSocketRequest.Builder
-
If true, the response will contain only high level information that is inexpensive to obtain.
- setSynchronizationContext(SynchronizationContext) - Method in class io.grpc.NameResolver.Args.Builder
- setTarget(String) - Method in class io.grpc.channelz.v1.ChannelData.Builder
-
The target this channel originally tried to connect to.
- setTarget(String) - Method in class io.grpc.InternalChannelz.ChannelStats.Builder
- setTargetAddress(InetSocketAddress) - Method in class io.grpc.HttpConnectProxiedSocketAddress.Builder
-
Sets the address to the target.
- setTargetBytes(ByteString) - Method in class io.grpc.channelz.v1.ChannelData.Builder
-
The target this channel originally tried to connect to.
- setTargets(int, String) - Method in class io.grpc.lookup.v1.RouteLookupResponse.Builder
-
Prioritized list (best one first) of addressable entities to use for routing, using syntax requested by the request target_type.
- setTargetType(String) - Method in class io.grpc.lookup.v1.RouteLookupRequest.Builder
-
Target type allows the client to specify what kind of target format it would like from RLS to allow it to find the regional server, e.g.
- setTargetTypeBytes(ByteString) - Method in class io.grpc.lookup.v1.RouteLookupRequest.Builder
-
Target type allows the client to specify what kind of target format it would like from RLS to allow it to find the regional server, e.g.
- setTcpiAdvmss(int) - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_advmss = 28;
- setTcpiAto(int) - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_ato = 10;
- setTcpiBackoff(int) - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_backoff = 5;
- setTcpiCaState(int) - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_ca_state = 2;
- setTcpiFackets(int) - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_fackets = 17;
- setTcpiLastAckRecv(int) - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_last_ack_recv = 21;
- setTcpiLastAckSent(int) - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_last_ack_sent = 19;
- setTcpiLastDataRecv(int) - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_last_data_recv = 20;
- setTcpiLastDataSent(int) - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_last_data_sent = 18;
- setTcpiLost(int) - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_lost = 15;
- setTcpInfo(InternalChannelz.TcpInfo) - Method in class io.grpc.InternalChannelz.SocketOptions.Builder
- setTcpiOptions(int) - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_options = 6;
- setTcpipAddress(Address.TcpIpAddress) - Method in class io.grpc.channelz.v1.Address.Builder
-
.grpc.channelz.v1.Address.TcpIpAddress tcpip_address = 1;
- setTcpipAddress(Address.TcpIpAddress.Builder) - Method in class io.grpc.channelz.v1.Address.Builder
-
.grpc.channelz.v1.Address.TcpIpAddress tcpip_address = 1;
- setTcpiPmtu(int) - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_pmtu = 22;
- setTcpiProbes(int) - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_probes = 4;
- setTcpiRcvMss(int) - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_rcv_mss = 12;
- setTcpiRcvSsthresh(int) - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_rcv_ssthresh = 23;
- setTcpiRcvWscale(int) - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_rcv_wscale = 8;
- setTcpiReordering(int) - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_reordering = 29;
- setTcpiRetrans(int) - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_retrans = 16;
- setTcpiRetransmits(int) - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_retransmits = 3;
- setTcpiRto(int) - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_rto = 9;
- setTcpiRtt(int) - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_rtt = 24;
- setTcpiRttvar(int) - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_rttvar = 25;
- setTcpiSacked(int) - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_sacked = 14;
- setTcpiSndCwnd(int) - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_snd_cwnd = 27;
- setTcpiSndMss(int) - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_snd_mss = 11;
- setTcpiSndSsthresh(int) - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_snd_ssthresh = 26;
- setTcpiSndWscale(int) - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_snd_wscale = 7;
- setTcpiState(int) - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_state = 1;
- setTcpiUnacked(int) - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
-
uint32 tcpi_unacked = 13;
- setThreshold(Integer) - Method in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig.FailurePercentageEjection.Builder
-
The failure percentage that will result in an address being considered an outlier.
- setThrottler(Throttler) - Method in class io.grpc.rls.CachingRlsLbClient.Builder
- setTicker(Ticker) - Method in class io.grpc.rls.AdaptiveThrottler.Builder
- setTicker(Ticker) - Method in class io.grpc.rls.CachingRlsLbClient.Builder
- setTimeMillis(CharSequence, long) - Method in class io.grpc.netty.AbstractHttp2Headers
- setTimeout(Duration) - Method in class io.grpc.binarylog.v1.ClientHeader.Builder
-
the RPC timeout
- setTimeout(Duration.Builder) - Method in class io.grpc.binarylog.v1.ClientHeader.Builder
-
the RPC timeout
- setTimestamp(Timestamp) - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
The timestamp of the binary log message
- setTimestamp(Timestamp) - Method in class io.grpc.channelz.v1.ChannelTraceEvent.Builder
-
When this event occurred.
- setTimestamp(Timestamp) - Method in class io.grpc.lb.v1.ClientStats.Builder
-
The timestamp of generating the report.
- setTimestamp(Timestamp.Builder) - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
The timestamp of the binary log message
- setTimestamp(Timestamp.Builder) - Method in class io.grpc.channelz.v1.ChannelTraceEvent.Builder
-
When this event occurred.
- setTimestamp(Timestamp.Builder) - Method in class io.grpc.lb.v1.ClientStats.Builder
-
The timestamp of generating the report.
- setTimestampNanos(long) - Method in class io.grpc.InternalChannelz.ChannelTrace.Event.Builder
- SETTINGS_TIMEOUT - Enum constant in enum io.grpc.internal.GrpcUtil.Http2Error
- setTls(Security.Tls) - Method in class io.grpc.channelz.v1.Security.Builder
-
.grpc.channelz.v1.Security.Tls tls = 1;
- setTls(Security.Tls.Builder) - Method in class io.grpc.channelz.v1.Security.Builder
-
.grpc.channelz.v1.Security.Tls tls = 1;
- setTrace(ChannelTrace) - Method in class io.grpc.channelz.v1.ChannelData.Builder
-
A trace of recent events on the channel.
- setTrace(ChannelTrace) - Method in class io.grpc.channelz.v1.ServerData.Builder
-
A trace of recent events on the server.
- setTrace(ChannelTrace.Builder) - Method in class io.grpc.channelz.v1.ChannelData.Builder
-
A trace of recent events on the channel.
- setTrace(ChannelTrace.Builder) - Method in class io.grpc.channelz.v1.ServerData.Builder
-
A trace of recent events on the server.
- setTracingEnabled(boolean) - Method in class io.grpc.internal.ManagedChannelImplBuilder
-
Disable or enable tracing features.
- setTracingEnabled(boolean) - Method in class io.grpc.internal.ServerImplBuilder
-
Disable or enable tracing features.
- setTracingEnabled(boolean) - Method in class io.grpc.netty.NettyChannelBuilder
- setTracingEnabled(boolean) - Method in class io.grpc.netty.NettyServerBuilder
- setTracingEnabled(NettyChannelBuilder, boolean) - Static method in class io.grpc.netty.InternalNettyChannelBuilder
- setTracingEnabled(NettyServerBuilder, boolean) - Static method in class io.grpc.netty.InternalNettyServerBuilder
- setTrailer(Trailer) - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
.grpc.binarylog.v1.Trailer trailer = 9;
- setTrailer(Trailer.Builder) - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
.grpc.binarylog.v1.Trailer trailer = 9;
- setTransportTracerFactory(TransportTracer.Factory) - Method in class io.grpc.netty.NettyChannelBuilder
- setTransportTracerFactory(TransportTracer.Factory) - Method in class io.grpc.netty.NettyServerBuilder
- setTransportTracerFactory(NettyChannelBuilder, TransportTracer.Factory) - Static method in class io.grpc.netty.InternalNettyChannelBuilder
- setType(Address.Type) - Method in class io.grpc.binarylog.v1.Address.Builder
-
.grpc.binarylog.v1.Address.Type type = 1;
- setType(GrpcLogEntry.EventType) - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
.grpc.binarylog.v1.GrpcLogEntry.EventType type = 4;
- setType(MethodDescriptor.MethodType) - Method in class io.grpc.MethodDescriptor.Builder
-
Sets the method type.
- setTypeValue(int) - Method in class io.grpc.binarylog.v1.Address.Builder
-
.grpc.binarylog.v1.Address.Type type = 1;
- setTypeValue(int) - Method in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
-
.grpc.binarylog.v1.GrpcLogEntry.EventType type = 4;
- setUdsAddress(Address.UdsAddress) - Method in class io.grpc.channelz.v1.Address.Builder
-
.grpc.channelz.v1.Address.UdsAddress uds_address = 2;
- setUdsAddress(Address.UdsAddress.Builder) - Method in class io.grpc.channelz.v1.Address.Builder
-
.grpc.channelz.v1.Address.UdsAddress uds_address = 2;
- setUnacked(int) - Method in class io.grpc.InternalChannelz.TcpInfo.Builder
- setUp() - Method in class io.grpc.internal.ClientCallImpl.CancellationHandler
- setUpDeadlineCancellation(Deadline, ScheduledExecutorService) - Method in class io.grpc.Context.CancellableContext
- setUserAgent(String) - Method in class io.grpc.internal.ClientTransportFactory.ClientTransportOptions
- setUsername(String) - Method in class io.grpc.HttpConnectProxiedSocketAddress.Builder
-
Sets the username used to connect to the proxy.
- setValidHost(String) - Method in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
-
string valid_host = 1;
- setValidHost(String) - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
-
string valid_host = 1;
- setValidHostBytes(ByteString) - Method in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
-
string valid_host = 1;
- setValidHostBytes(ByteString) - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
-
string valid_host = 1;
- setValidTargets(int, String) - Method in class io.grpc.lookup.v1.RouteLookupConfig.Builder
-
This is a list of all the possible targets that can be returned by the lookup service.
- setValue(Any) - Method in class io.grpc.channelz.v1.Address.OtherAddress.Builder
-
The actual address message.
- setValue(Any) - Method in class io.grpc.channelz.v1.Security.OtherSecurity.Builder
-
The actual security details message.
- setValue(Any.Builder) - Method in class io.grpc.channelz.v1.Address.OtherAddress.Builder
-
The actual address message.
- setValue(Any.Builder) - Method in class io.grpc.channelz.v1.Security.OtherSecurity.Builder
-
The actual security details message.
- setValue(ByteString) - Method in class io.grpc.binarylog.v1.MetadataEntry.Builder
-
bytes value = 2;
- setValue(CharSequence) - Method in class io.grpc.netty.GrpcHttp2OutboundHeaders.Itr
- setValue(String) - Method in class io.grpc.channelz.v1.SocketOption.Builder
-
The human readable value of this socket option.
- setValueBytes(ByteString) - Method in class io.grpc.channelz.v1.SocketOption.Builder
-
The human readable value of this socket option.
- setVerification(AdvancedTlsX509TrustManager.Verification) - Method in class io.grpc.util.AdvancedTlsX509TrustManager.Builder
-
Sets
AdvancedTlsX509TrustManager.Verification
, mode when authenticating the peer certificate. - severity - Variable in class io.grpc.InternalChannelz.ChannelTrace.Event.Builder
- severity - Variable in class io.grpc.InternalChannelz.ChannelTrace.Event
- Severity() - Constructor for enum io.grpc.InternalChannelz.ChannelTrace.Event.Severity
- Severity(int) - Constructor for enum io.grpc.channelz.v1.ChannelTraceEvent.Severity
- severity_ - Variable in class io.grpc.channelz.v1.ChannelTraceEvent.Builder
- severity_ - Variable in class io.grpc.channelz.v1.ChannelTraceEvent
- SEVERITY_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.ChannelTraceEvent
- 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(SharedResourceHolder.ScheduledExecutorFactory) - Constructor for class io.grpc.internal.SharedResourceHolder
- SharedResourceHolder.Instance - Class in io.grpc.internal
- SharedResourceHolder.Resource<T> - Interface in io.grpc.internal
-
Defines a resource, and the way to create and destroy instances of it.
- SharedResourceHolder.ScheduledExecutorFactory - Interface in io.grpc.internal
- SharedResourcePool<T> - Class in io.grpc.internal
-
An ObjectPool backed by a
SharedResourceHolder.Resource
. - SharedResourcePool(SharedResourceHolder.Resource<T>) - Constructor for class io.grpc.internal.SharedResourcePool
- sharedResourceReferenceCounter - Variable in class io.grpc.netty.NettyServer
- SharedResourceReferenceCounter() - Constructor for class io.grpc.netty.NettyServer.SharedResourceReferenceCounter
- shortName() - Method in class io.grpc.InternalLogId
- SHOULD_LOG_SERVER_LISTS - Static variable in class io.grpc.grpclb.GrpclbState
- shouldBeCountedForInUse - Variable in class io.grpc.internal.AbstractClientStream
- shouldBeCountedForInUse - Variable in class io.grpc.netty.CreateStreamCommand
- shouldBeCountedForInUse() - Method in class io.grpc.internal.AbstractClientStream
-
Returns true if this stream should be counted when determining the in-use state of the transport.
- shouldBeCountedForInUse() - Method in class io.grpc.netty.CreateStreamCommand
- shouldBeCountedForInUse(CallOptions) - Static method in class io.grpc.internal.GrpcUtil
-
Returns true if an RPC with the given properties should be counted when calculating the in-use state of a transport.
- shouldCloseStreamWithHeaders(CancelServerStreamCommand, Http2Connection) - Static method in class io.grpc.netty.NettyServerHandler
- shouldCompose(CompositeByteBuf, ByteBuf, int) - Static method in class io.grpc.netty.NettyAdaptiveCumulator
- shouldEscape(char) - Static method in class io.grpc.internal.GrpcUtil.AuthorityEscaper
- shouldInvalidateEldestEntry(RlsProtoData.RouteLookupRequest, CachingRlsLbClient.CacheEntry, long) - Method in class io.grpc.rls.CachingRlsLbClient.RlsAsyncLruCache
- shouldInvalidateEldestEntry(K, V, long) - Method in class io.grpc.rls.LinkedHashLruCache
-
Determines if the eldest entry should be kept or not when the cache size limit is reached.
- shouldRetry - Variable in class io.grpc.internal.RetriableStream.RetryPlan
- shouldThrottle() - Method in class io.grpc.rls.AdaptiveThrottler
- shouldThrottle() - Method in class io.grpc.rls.CachingRlsLbClient.HappyThrottler
- shouldThrottle() - Method in interface io.grpc.rls.Throttler
-
Checks if a given request should be throttled by the client.
- shouldThrottle(float) - Method in class io.grpc.rls.AdaptiveThrottler
- shouldUseJndi(boolean, boolean, String) - Static method in class io.grpc.internal.DnsNameResolver
- shouldWaitOnServiceConfig() - Method in class io.grpc.internal.ServiceConfigState
-
Returns
true
if it RPCs should wait on a service config resolution. - SHUFFLE_ADDRESS_LIST_KEY - Static variable in class io.grpc.internal.PickFirstLoadBalancerProvider
- shuffleAddressList - Variable in class io.grpc.internal.PickFirstLeafLoadBalancer.PickFirstLeafLoadBalancerConfig
- shuffleAddressList - Variable in class io.grpc.internal.PickFirstLoadBalancer.PickFirstLoadBalancerConfig
- shutdown - Variable in class io.grpc.inprocess.InProcessServer
- shutdown - Variable in class io.grpc.inprocess.InProcessTransport
- shutdown - Variable in class io.grpc.internal.DnsNameResolver
- shutdown - Variable in class io.grpc.internal.KeepAliveManager
- shutdown - Variable in class io.grpc.internal.ManagedChannelImpl
- shutdown - Variable in class io.grpc.internal.ManagedChannelImpl.SubchannelImpl
- shutdown - Variable in class io.grpc.internal.ManagedChannelOrphanWrapper.ManagedChannelReference
- shutdown - Variable in class io.grpc.internal.OobChannel
- shutdown - Variable in class io.grpc.internal.ServerImpl
- shutdown() - Method in class io.grpc.grpclb.GrpclbLoadBalancer
- shutdown() - Method in class io.grpc.grpclb.GrpclbState
- shutdown() - Method in class io.grpc.inprocess.InProcessServer
- shutdown() - Method in class io.grpc.inprocess.InProcessTransport
- shutdown() - Method in class io.grpc.internal.AutoConfiguredLoadBalancerFactory.AutoConfiguredLoadBalancer
- shutdown() - Method in class io.grpc.internal.AutoConfiguredLoadBalancerFactory.NoopLoadBalancer
- shutdown() - Method in class io.grpc.internal.DnsNameResolver
- shutdown() - Method in class io.grpc.internal.ForwardingManagedChannel
- shutdown() - Method in class io.grpc.internal.ForwardingNameResolver
- shutdown() - Method in interface io.grpc.internal.InternalServer
-
Initiates an orderly shutdown of the server.
- shutdown() - Method in class io.grpc.internal.ManagedChannelImpl.RealChannel
- shutdown() - Method in class io.grpc.internal.ManagedChannelImpl.RestrictedScheduledExecutor
- shutdown() - Method in class io.grpc.internal.ManagedChannelImpl
-
Initiates an orderly shutdown in which preexisting calls continue but new calls are immediately cancelled.
- shutdown() - Method in class io.grpc.internal.ManagedChannelImpl.SubchannelImpl
- shutdown() - Method in class io.grpc.internal.ManagedChannelOrphanWrapper
- shutdown() - Method in class io.grpc.internal.OobChannel
- shutdown() - Method in class io.grpc.internal.PickFirstLeafLoadBalancer
- shutdown() - Method in class io.grpc.internal.PickFirstLoadBalancer
- shutdown() - Method in class io.grpc.internal.RetryingNameResolver
- 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.netty.NettyServer
- shutdown() - Method in class io.grpc.netty.NettyServerTransport
- shutdown() - Method in class io.grpc.netty.UdsNameResolver
- shutdown() - Method in class io.grpc.rls.LbPolicyConfiguration.ChildPolicyWrapper
- shutdown() - Method in class io.grpc.rls.RlsLoadBalancer
- shutdown() - Method in class io.grpc.Server
-
Initiates an orderly shutdown in which preexisting calls continue but new calls are rejected.
- shutdown() - Method in class io.grpc.servlet.jakarta.ServletServerBuilder.InternalServerImpl
- shutdown() - Method in class io.grpc.servlet.jakarta.ServletServerBuilder.ServerTransportImpl
- shutdown() - Method in class io.grpc.servlet.ServletServerBuilder.InternalServerImpl
- shutdown() - Method in class io.grpc.servlet.ServletServerBuilder.ServerTransportImpl
- shutdown() - Method in class io.grpc.stub.ClientCalls.ThreadlessExecutor
-
Called after final call to
ClientCalls.ThreadlessExecutor.waitAndDrain()
, from same thread. - shutdown() - Method in class io.grpc.util.ForwardingLoadBalancer
- shutdown() - Method in class io.grpc.util.ForwardingSubchannel
- shutdown() - Method in class io.grpc.util.GracefulSwitchLoadBalancer
- shutdown() - Method in class io.grpc.util.MultiChildLoadBalancer.ChildLbState
-
Override for unique behavior such as delayed shutdowns of subchannels.
- shutdown() - Method in class io.grpc.util.MultiChildLoadBalancer
- shutdown() - Method in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionSubchannel
- shutdown() - Method in class io.grpc.util.OutlierDetectionLoadBalancer
- shutdown(Status) - Method in class io.grpc.inprocess.InProcessTransport
- shutdown(Status) - Method in class io.grpc.internal.CallCredentialsApplyingTransportFactory.CallCredentialsApplyingTransport
- shutdown(Status) - Method in class io.grpc.internal.DelayedClientTransport
-
Prevents creating any new streams.
- shutdown(Status) - Method in class io.grpc.internal.ForwardingConnectionClientTransport
- shutdown(Status) - Method in class io.grpc.internal.InternalSubchannel
- shutdown(Status) - Method in interface io.grpc.internal.ManagedClientTransport
-
Initiates an orderly shutdown of the transport.
- shutdown(Status) - Method in class io.grpc.netty.NettyClientTransport
- SHUTDOWN - Enum constant in enum io.grpc.channelz.v1.ChannelConnectivityState.State
-
SHUTDOWN = 5;
- SHUTDOWN - Enum constant in enum io.grpc.ConnectivityState
-
This channel has started shutting down.
- SHUTDOWN - Static variable in class io.grpc.stub.ClientCalls.ThreadlessExecutor
- SHUTDOWN_NOW_STATUS - Static variable in class io.grpc.internal.ManagedChannelImpl
- SHUTDOWN_STATUS - Static variable in class io.grpc.internal.ManagedChannelImpl
- SHUTDOWN_TIMEOUT_MS - Static variable in class io.grpc.grpclb.CachedSubchannelPool
- SHUTDOWN_VALUE - Static variable in enum io.grpc.channelz.v1.ChannelConnectivityState.State
-
SHUTDOWN = 5;
- shutdownDelayed - Variable in class io.grpc.internal.MaxConnectionIdleManager
- shutdownDueToUpdateTask - Variable in class io.grpc.internal.InternalSubchannel
- shutdownDueToUpdateTransport - Variable in class io.grpc.internal.InternalSubchannel
- shutdownFuture - Variable in class io.grpc.internal.KeepAliveManager
- shutdownFuture - Variable in class io.grpc.internal.MaxConnectionIdleManager
- shutdownInitiated - Variable in class io.grpc.internal.InternalSubchannel.TransportListener
- shutdownLbComm() - Method in class io.grpc.grpclb.GrpclbState
- shutdownLbRpc() - Method in class io.grpc.grpclb.GrpclbState
- shutdownNameResolverAndLoadBalancer(boolean) - Method in class io.grpc.internal.ManagedChannelImpl
- shutdownNow() - Method in class io.grpc.internal.ForwardingManagedChannel
- shutdownNow() - Method in class io.grpc.internal.ManagedChannelImpl.RealChannel
- shutdownNow() - Method in class io.grpc.internal.ManagedChannelImpl.RestrictedScheduledExecutor
- shutdownNow() - Method in class io.grpc.internal.ManagedChannelImpl
-
Initiates a forceful shutdown in which preexisting and new calls are cancelled.
- shutdownNow() - Method in class io.grpc.internal.ManagedChannelOrphanWrapper
- shutdownNow() - Method in class io.grpc.internal.OobChannel
- shutdownNow() - Method in class io.grpc.internal.ServerImpl
- 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.
- shutdownNow(Status) - Method in class io.grpc.inprocess.InProcessTransport
- shutdownNow(Status) - Method in class io.grpc.internal.CallCredentialsApplyingTransportFactory.CallCredentialsApplyingTransport
- shutdownNow(Status) - Method in class io.grpc.internal.DelayedClientTransport
-
Shuts down this transport and cancels all streams that it owns, hence immediately terminates this transport.
- shutdownNow(Status) - Method in class io.grpc.internal.ForwardingConnectionClientTransport
- shutdownNow(Status) - Method in class io.grpc.internal.InternalSubchannel
- shutdownNow(Status) - Method in interface io.grpc.internal.ManagedClientTransport
-
Initiates a forceful shutdown in which preexisting and new calls are closed.
- shutdownNow(Status) - Method in interface io.grpc.internal.ServerTransport
-
Initiates a forceful shutdown in which preexisting and new calls are closed.
- shutdownNow(Status) - Method in class io.grpc.netty.NettyClientTransport
- shutdownNow(Status) - Method in class io.grpc.netty.NettyServerTransport
- shutdownNow(Status) - Method in class io.grpc.servlet.jakarta.ServletServerBuilder.ServerTransportImpl
- shutdownNow(Status) - Method in class io.grpc.servlet.ServletServerBuilder.ServerTransportImpl
- shutdownNowed - Variable in class io.grpc.internal.ManagedChannelImpl
- shutdownNowStatus - Variable in class io.grpc.internal.ServerImpl
-
non-
null
if immediate shutdown has been requested. - shutdownReason - Variable in class io.grpc.internal.InternalSubchannel
- shutdownRemaining(PickFirstLeafLoadBalancer.SubchannelData) - Method in class io.grpc.internal.PickFirstLeafLoadBalancer
-
Shuts down remaining subchannels.
- shutdownRemoved(List<MultiChildLoadBalancer.ChildLbState>) - Method in class io.grpc.util.MultiChildLoadBalancer
- shutdownStatus - Variable in class io.grpc.inprocess.InProcessTransport
- shutdownStatus - Variable in class io.grpc.internal.CallCredentialsApplyingTransportFactory.CallCredentialsApplyingTransport
- shutdownStatus - Variable in class io.grpc.internal.DelayedClientTransport.PickerState
-
When
shutdownStatus != null && !hasPendingStreams()
, then the transport is considered terminated. - shutdownStatus - Variable in class io.grpc.internal.ManagedChannelImpl.UncommittedRetriableStreamsRegistry
- shutdownStatus - Variable in class io.grpc.netty.ClientTransportLifecycleManager
-
null iff !transportShutdown.
- ShutdownSubchannelTask(LoadBalancer.Subchannel) - Constructor for class io.grpc.grpclb.CachedSubchannelPool.ShutdownSubchannelTask
- shutdownTask - Variable in class io.grpc.internal.MaxConnectionIdleManager
- shutdownThrowable - Variable in class io.grpc.netty.ClientTransportLifecycleManager
-
null iff !transportShutdown.
- shutdownTimer - Variable in class io.grpc.grpclb.CachedSubchannelPool.CacheEntry
- 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
- Simple Unary (1 request, 1 response) RPC - Search tag in class io.grpc.ClientCall
- Section
- SingleMessageProducer(InputStream) - Constructor for class io.grpc.inprocess.InProcessTransport.SingleMessageProducer
- SingleMessageProducer(InputStream) - Constructor for class io.grpc.internal.MessageDeframer.SingleMessageProducer
- sink - Variable in class io.grpc.internal.MessageFramer
- sink - Variable in class io.grpc.internal.MetricRecorderImpl.BatchRecorderImpl
- sink - Variable in class io.grpc.netty.NettyClientStream
- sink - Variable in class io.grpc.netty.NettyServerStream
- sink - Variable in class io.grpc.protobuf.services.BinaryLogProviderImpl
- sink - Variable in class io.grpc.protobuf.services.BinlogHelper.SinkWriterImpl
- sink - Variable in class io.grpc.servlet.jakarta.ServletServerStream
- sink - Variable in class io.grpc.servlet.ServletServerStream
- Sink() - Constructor for class io.grpc.netty.NettyClientStream.Sink
- Sink() - Constructor for class io.grpc.netty.NettyServerStream.Sink
- Sink() - Constructor for class io.grpc.servlet.jakarta.ServletServerStream.Sink
- Sink() - Constructor for class io.grpc.servlet.ServletServerStream.Sink
- SinkWriter() - Constructor for class io.grpc.protobuf.services.BinlogHelper.SinkWriter
- SinkWriterImpl(BinaryLogSink, BinlogHelper.TimeProvider, int, int) - Constructor for class io.grpc.protobuf.services.BinlogHelper.SinkWriterImpl
- size - Variable in class io.grpc.internal.PickFirstLeafLoadBalancer.Index
- size - Variable in class io.grpc.Metadata
- size - Variable in class io.grpc.PersistentHashArrayMappedTrie.CompressedIndex
- size - Variable in class io.grpc.rls.LinkedHashLruCache.SizedValue
- size() - Method in class io.grpc.internal.PickFirstLeafLoadBalancer.Index
- size() - Method in class io.grpc.netty.AbstractHttp2Headers
- size() - Method in class io.grpc.netty.GrpcHttp2HeadersUtils.GrpcHttp2InboundHeaders
- size() - Method in class io.grpc.netty.GrpcHttp2HeadersUtils.GrpcHttp2RequestHeaders
-
This method is called in tests only.
- size() - Method in class io.grpc.netty.GrpcHttp2OutboundHeaders
- size() - Method in class io.grpc.PersistentHashArrayMappedTrie.CollisionLeaf
- size() - Method in class io.grpc.PersistentHashArrayMappedTrie.CompressedIndex
- size() - Method in class io.grpc.PersistentHashArrayMappedTrie.Leaf
- size() - Method in interface io.grpc.PersistentHashArrayMappedTrie.Node
- SIZE - Enum constant in enum io.grpc.rls.LruCache.EvictionType
-
Evicted due to size limit.
- SizedValue(int, V) - Constructor for class io.grpc.rls.LinkedHashLruCache.SizedValue
- SizeEnforcingInputStream(InputStream, int, StatsTraceContext) - Constructor for class io.grpc.internal.MessageDeframer.SizeEnforcingInputStream
- SizeHandlingEvictionListener(LruCache.EvictionListener<K, V>) - Constructor for class io.grpc.rls.LinkedHashLruCache.SizeHandlingEvictionListener
- skip(long) - Method in class io.grpc.internal.MessageDeframer.SizeEnforcingInputStream
- skip(long) - Method in class io.grpc.internal.ReadableBuffers.BufferInputStream
- SKIP_OP - Static variable in class io.grpc.internal.CompositeReadableBuffer
- skipBytes(int) - Method in class io.grpc.internal.CompositeReadableBuffer
- skipBytes(int) - Method in class io.grpc.internal.ForwardingReadableBuffer
- skipBytes(int) - Method in class io.grpc.internal.GzipInflatingBuffer.GzipMetadataReader
-
Skips
length
bytes, adding them to the CRC and addinglength
tobytesConsumed
. - skipBytes(int) - Method in interface io.grpc.internal.ReadableBuffer
-
Increments the read position by the given length.
- skipBytes(int) - Method in class io.grpc.internal.ReadableBuffers.ByteArrayWrapper
- skipBytes(int) - Method in class io.grpc.internal.ReadableBuffers.ByteReadableBufferWrapper
- skipBytes(int) - Method in class io.grpc.netty.NettyReadableBuffer
- Slot(long) - Constructor for class io.grpc.rls.AdaptiveThrottler.TimeBasedAccumulator.Slot
- slotNanos - Variable in class io.grpc.rls.AdaptiveThrottler.TimeBasedAccumulator
-
The number of nanoseconds in each slot.
- slots - Variable in class io.grpc.rls.AdaptiveThrottler.TimeBasedAccumulator
-
The array of slots.
- sndCwnd - Variable in class io.grpc.InternalChannelz.TcpInfo.Builder
- sndCwnd - Variable in class io.grpc.InternalChannelz.TcpInfo
- sndMss - Variable in class io.grpc.InternalChannelz.TcpInfo.Builder
- sndMss - Variable in class io.grpc.InternalChannelz.TcpInfo
- sndSsthresh - Variable in class io.grpc.InternalChannelz.TcpInfo.Builder
- sndSsthresh - Variable in class io.grpc.InternalChannelz.TcpInfo
- sndWscale - Variable in class io.grpc.InternalChannelz.TcpInfo.Builder
- sndWscale - Variable in class io.grpc.InternalChannelz.TcpInfo
- SO_LINGER - Static variable in class io.grpc.protobuf.services.ChannelzProtoUtil
- SO_TIMEOUT - Static variable in class io.grpc.protobuf.services.ChannelzProtoUtil
- Socket - Class in io.grpc.channelz.v1
-
Information about an actual connection.
- Socket() - Constructor for class io.grpc.channelz.v1.Socket
- Socket(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.channelz.v1.Socket
- socket_ - Variable in class io.grpc.channelz.v1.GetSocketResponse.Builder
- socket_ - Variable in class io.grpc.channelz.v1.GetSocketResponse
- SOCKET_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.GetSocketResponse
- SOCKET_ID_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.GetSocketRequest
- SOCKET_ID_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.SocketRef
- SOCKET_REF_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.Channel
- SOCKET_REF_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.GetServerSocketsResponse
- SOCKET_REF_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.Subchannel
- Socket.Builder - Class in io.grpc.channelz.v1
-
Information about an actual connection.
- socketAndEnginePeerVerifier - Variable in class io.grpc.util.AdvancedTlsX509TrustManager.Builder
- socketAndEnginePeerVerifier - Variable in class io.grpc.util.AdvancedTlsX509TrustManager
- socketBuilder_ - Variable in class io.grpc.channelz.v1.GetSocketResponse.Builder
- SocketData - Class in io.grpc.channelz.v1
-
SocketData is data associated for a specific Socket.
- SocketData() - Constructor for class io.grpc.channelz.v1.SocketData
- SocketData(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.channelz.v1.SocketData
- SocketData.Builder - Class in io.grpc.channelz.v1
-
SocketData is data associated for a specific Socket.
- SocketDataOrBuilder - Interface in io.grpc.channelz.v1
- socketId_ - Variable in class io.grpc.channelz.v1.GetSocketRequest.Builder
- socketId_ - Variable in class io.grpc.channelz.v1.GetSocketRequest
- socketId_ - Variable in class io.grpc.channelz.v1.SocketRef.Builder
- socketId_ - Variable in class io.grpc.channelz.v1.SocketRef
- SocketOption - Class in io.grpc.channelz.v1
-
SocketOption represents socket options for a socket.
- SocketOption() - Constructor for class io.grpc.channelz.v1.SocketOption
- SocketOption(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.channelz.v1.SocketOption
- SocketOption.Builder - Class in io.grpc.channelz.v1
-
SocketOption represents socket options for a socket.
- SocketOptionLinger - Class in io.grpc.channelz.v1
-
For use with SocketOption's additional field.
- SocketOptionLinger() - Constructor for class io.grpc.channelz.v1.SocketOptionLinger
- SocketOptionLinger(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.channelz.v1.SocketOptionLinger
- SocketOptionLinger.Builder - Class in io.grpc.channelz.v1
-
For use with SocketOption's additional field.
- SocketOptionLingerOrBuilder - Interface in io.grpc.channelz.v1
- SocketOptionOrBuilder - Interface in io.grpc.channelz.v1
- socketOptions - Variable in class io.grpc.InternalChannelz.SocketStats
- SocketOptions(Integer, Integer, InternalChannelz.TcpInfo, Map<String, String>) - Constructor for class io.grpc.InternalChannelz.SocketOptions
-
Creates an instance.
- SocketOptionTcpInfo - Class in io.grpc.channelz.v1
-
For use with SocketOption's additional field.
- SocketOptionTcpInfo() - Constructor for class io.grpc.channelz.v1.SocketOptionTcpInfo
- SocketOptionTcpInfo(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.channelz.v1.SocketOptionTcpInfo
- SocketOptionTcpInfo.Builder - Class in io.grpc.channelz.v1
-
For use with SocketOption's additional field.
- SocketOptionTcpInfoOrBuilder - Interface in io.grpc.channelz.v1
- SocketOptionTimeout - Class in io.grpc.channelz.v1
-
For use with SocketOption's additional field.
- SocketOptionTimeout() - Constructor for class io.grpc.channelz.v1.SocketOptionTimeout
- SocketOptionTimeout(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.channelz.v1.SocketOptionTimeout
- SocketOptionTimeout.Builder - Class in io.grpc.channelz.v1
-
For use with SocketOption's additional field.
- SocketOptionTimeoutOrBuilder - Interface in io.grpc.channelz.v1
- SocketOrBuilder - Interface in io.grpc.channelz.v1
- SocketRef - Class in io.grpc.channelz.v1
-
SocketRef is a reference to a Socket.
- SocketRef() - Constructor for class io.grpc.channelz.v1.SocketRef
- SocketRef(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.channelz.v1.SocketRef
- socketRef_ - Variable in class io.grpc.channelz.v1.Channel.Builder
- socketRef_ - Variable in class io.grpc.channelz.v1.Channel
- socketRef_ - Variable in class io.grpc.channelz.v1.GetServerSocketsResponse.Builder
- socketRef_ - Variable in class io.grpc.channelz.v1.GetServerSocketsResponse
- socketRef_ - Variable in class io.grpc.channelz.v1.Subchannel.Builder
- socketRef_ - Variable in class io.grpc.channelz.v1.Subchannel
- SocketRef.Builder - Class in io.grpc.channelz.v1
-
SocketRef is a reference to a Socket.
- socketRefBuilder_ - Variable in class io.grpc.channelz.v1.Channel.Builder
- socketRefBuilder_ - Variable in class io.grpc.channelz.v1.GetServerSocketsResponse.Builder
- socketRefBuilder_ - Variable in class io.grpc.channelz.v1.Subchannel.Builder
- SocketRefOrBuilder - Interface in io.grpc.channelz.v1
- sockets - Variable in class io.grpc.InternalChannelz.ChannelStats.Builder
- 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.
- socketToProto(SocketAddress) - Static method in class io.grpc.protobuf.services.BinlogHelper
- soTimeoutMillis - Variable in class io.grpc.InternalChannelz.SocketOptions
- SpiffeBundle(Map<String, Long>, Map<String, List<X509Certificate>>) - Constructor for class io.grpc.internal.SpiffeUtil.SpiffeBundle
- SpiffeId(String, String) - Constructor for class io.grpc.internal.SpiffeUtil.SpiffeId
- SpiffeUtil - Class in io.grpc.internal
-
Provides utilities to manage SPIFFE bundles, extract SPIFFE IDs from X.509 certificate chains, and parse SPIFFE IDs.
- SpiffeUtil() - Constructor for class io.grpc.internal.SpiffeUtil
- SpiffeUtil.SpiffeBundle - Class in io.grpc.internal
-
Represents a SPIFFE trust bundle; that is, a map from trust domain to set of trusted certificates.
- SpiffeUtil.SpiffeId - Class in io.grpc.internal
-
Represents a SPIFFE ID as defined in the SPIFFE standard.
- SquelchLateMessagesAvailableDeframerListener - Class in io.grpc.internal
-
A delegating Listener that throws away notifications of messagesAvailable() after the deframer has closed or failed.
- SquelchLateMessagesAvailableDeframerListener(MessageDeframer.Listener) - Constructor for class io.grpc.internal.SquelchLateMessagesAvailableDeframerListener
- SrvRecord(String, int) - Constructor for class io.grpc.internal.DnsNameResolver.SrvRecord
- sslContext - Variable in class io.grpc.netty.NettyChannelBuilder.DefaultProtocolNegotiator
- sslContext - Variable in class io.grpc.netty.ProtocolNegotiators.ClientTlsHandler
- sslContext - Variable in class io.grpc.netty.ProtocolNegotiators.ClientTlsProtocolNegotiator
- sslContext - Variable in class io.grpc.netty.ProtocolNegotiators.ServerTlsHandler
- sslContext - Variable in class io.grpc.netty.ProtocolNegotiators.TlsProtocolNegotiatorClientFactory
- sslContext - Variable in class io.grpc.netty.ProtocolNegotiators.TlsProtocolNegotiatorServerFactory
- 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.
- STALE_AGE_FIELD_NUMBER - Static variable in class io.grpc.lookup.v1.RouteLookupConfig
- STALE_HEADER_DATA_FIELD_NUMBER - Static variable in class io.grpc.lookup.v1.RouteLookupRequest
- staleAge_ - Variable in class io.grpc.lookup.v1.RouteLookupConfig.Builder
- staleAge_ - Variable in class io.grpc.lookup.v1.RouteLookupConfig
- staleAgeBuilder_ - Variable in class io.grpc.lookup.v1.RouteLookupConfig.Builder
- staleAgeInNanos - Variable in class io.grpc.rls.AutoValue_RlsProtoData_RouteLookupConfig.Builder
- staleAgeInNanos - Variable in class io.grpc.rls.AutoValue_RlsProtoData_RouteLookupConfig
- staleAgeInNanos() - Method in class io.grpc.rls.AutoValue_RlsProtoData_RouteLookupConfig
- staleAgeInNanos() - Method in class io.grpc.rls.RlsProtoData.RouteLookupConfig
-
Returns the time when an entry will be in a staled status.
- staleAgeInNanos(long) - Method in class io.grpc.rls.AutoValue_RlsProtoData_RouteLookupConfig.Builder
- staleAgeInNanos(long) - Method in class io.grpc.rls.RlsProtoData.RouteLookupConfig.Builder
- staleAgeNanos - Variable in class io.grpc.rls.CachingRlsLbClient
- staleHeaderData_ - Variable in class io.grpc.lookup.v1.RouteLookupRequest.Builder
- staleHeaderData_ - Variable in class io.grpc.lookup.v1.RouteLookupRequest
- staleTime - Variable in class io.grpc.rls.CachingRlsLbClient.DataCacheEntry
- STANDARD_NAME - Enum constant in enum io.grpc.channelz.v1.Security.Tls.CipherSuiteCase
- STANDARD_NAME_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.Security.Tls
- standardDeviation(Collection<Double>, double) - Static method in class io.grpc.util.OutlierDetectionLoadBalancer.SuccessRateOutlierEjectionAlgorithm
-
Calculates the standard deviation for the given values and their mean.
- start() - Method in class io.grpc.grpclb.GrpclbState.LbStream
- start() - Method in class io.grpc.internal.ServerImpl
-
Bind and start the server.
- start() - Method in class io.grpc.protobuf.services.HealthCheckingLoadBalancerFactory.HealthCheckState.HcStream
- start() - Method in class io.grpc.Server
-
Bind and start the server.
- 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(ClientCall.Listener<RespT>, Metadata) - Method in class io.grpc.internal.ClientCallImpl
- start(ClientCall.Listener<RespT>, Metadata) - Method in class io.grpc.internal.DelayedClientCall
- start(ClientCall.Listener<RespT>, Metadata) - Method in class io.grpc.internal.ManagedChannelImpl.ConfigSelectingClientCall
- start(ClientCall.Listener<RespT>, Metadata) - Method in class io.grpc.stub.MetadataUtils.HeaderAttachingClientInterceptor.HeaderAttachingClientCall
- start(ClientCall.Listener<RespT>, Metadata) - Method in class io.grpc.stub.MetadataUtils.MetadataCapturingClientInterceptor.MetadataCapturingClientCall
- start(ClientStreamListener) - Method in class io.grpc.inprocess.InProcessTransport.InProcessStream.InProcessClientStream
- 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.DelayedStream
- start(ClientStreamListener) - Method in class io.grpc.internal.FailingClientStream
- start(ClientStreamListener) - Method in class io.grpc.internal.ForwardingClientStream
- start(ClientStreamListener) - Method in class io.grpc.internal.NoopClientStream
- start(ClientStreamListener) - Method in class io.grpc.internal.RetriableStream
-
Starts the first PRC attempt.
- start(ManagedClientTransport.Listener) - Method in class io.grpc.inprocess.InProcessTransport
- start(ManagedClientTransport.Listener) - Method in class io.grpc.internal.DelayedClientTransport
- start(ManagedClientTransport.Listener) - Method in class io.grpc.internal.ForwardingConnectionClientTransport
- start(ManagedClientTransport.Listener) - Method in interface io.grpc.internal.ManagedClientTransport
-
Starts transport.
- start(ManagedClientTransport.Listener) - Method in class io.grpc.netty.NettyClientTransport
- start(ServerListener) - Method in class io.grpc.inprocess.InProcessServer
- start(ServerListener) - Method in interface io.grpc.internal.InternalServer
-
Starts transport.
- start(ServerListener) - Method in class io.grpc.netty.NettyServer
- start(ServerListener) - Method in class io.grpc.servlet.jakarta.ServletServerBuilder.InternalServerImpl
- start(ServerListener) - Method in class io.grpc.servlet.ServletServerBuilder.InternalServerImpl
- start(ServerTransportListener) - Method in class io.grpc.netty.NettyServerTransport
- start(LoadBalancer.SubchannelStateListener) - Method in class io.grpc.internal.ManagedChannelImpl.SubchannelImpl
- start(LoadBalancer.SubchannelStateListener) - Method in class io.grpc.LoadBalancer.Subchannel
-
Starts the Subchannel.
- start(LoadBalancer.SubchannelStateListener) - Method in class io.grpc.protobuf.services.HealthCheckingLoadBalancerFactory.SubchannelImpl
- start(LoadBalancer.SubchannelStateListener) - Method in class io.grpc.util.ForwardingSubchannel
- start(LoadBalancer.SubchannelStateListener) - Method in class io.grpc.util.HealthProducerHelper.HealthProducerSubchannel
- start(LoadBalancer.SubchannelStateListener) - Method in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionSubchannel
- start(NameResolver.Listener) - Method in class io.grpc.internal.ForwardingNameResolver
-
Deprecated.
- start(NameResolver.Listener) - Method in class io.grpc.NameResolver
-
Starts the resolution.
- start(NameResolver.Listener2) - Method in class io.grpc.internal.DnsNameResolver
- start(NameResolver.Listener2) - Method in class io.grpc.internal.ForwardingNameResolver
- start(NameResolver.Listener2) - Method in class io.grpc.internal.RetryingNameResolver
- start(NameResolver.Listener2) - Method in class io.grpc.NameResolver
-
Starts the resolution.
- start(NameResolver.Listener2) - Method in class io.grpc.netty.UdsNameResolver
- start(ChannelHandlerContext) - Method in class io.grpc.netty.NettyServerHandler.GracefulShutdown
-
Sends out first GOAWAY and ping, and schedules second GOAWAY and close.
- start(Runnable, ScheduledExecutorService) - Method in class io.grpc.internal.MaxConnectionIdleManager
-
Start the initial scheduled shutdown given the transport status reaches max connection idle.
- START_CHANNEL_ID_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.GetTopChannelsRequest
- START_SERVER_ID_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.GetServersRequest
- START_SOCKET_ID_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.GetServerSocketsRequest
- StartableListener() - Constructor for class io.grpc.stub.ClientCalls.StartableListener
- startCall(ClientCall<ReqT, RespT>, ClientCalls.StartableListener<RespT>) - Static method in class io.grpc.stub.ClientCalls
- startCall(ServerCall<ReqT, RespT>, Metadata) - Method in class io.grpc.ServerInterceptors.InterceptCallHandler
- startCall(ServerCall<ReqT, RespT>, Metadata) - Method in class io.grpc.stub.ServerCalls.StreamingServerCallHandler
- startCall(ServerCall<ReqT, RespT>, Metadata) - Method in class io.grpc.stub.ServerCalls.UnaryServerCallHandler
- startCall(ServerCall<RequestT, ResponseT>, Metadata) - Method in interface io.grpc.ServerCallHandler
-
Starts asynchronous processing of an incoming call.
- startChannelId_ - Variable in class io.grpc.channelz.v1.GetTopChannelsRequest.Builder
- startChannelId_ - Variable in class io.grpc.channelz.v1.GetTopChannelsRequest
- started - Variable in class io.grpc.internal.FailingClientStream
- started - Variable in class io.grpc.internal.ManagedChannelImpl.SubchannelImpl
- started - Variable in class io.grpc.internal.ServerImpl
- StartEntry() - Constructor for class io.grpc.internal.RetriableStream.StartEntry
- startFallbackChildPolicy() - Method in class io.grpc.rls.CachingRlsLbClient.RlsPicker
- startIdx - Variable in class io.grpc.Metadata.IterableAt
- startInternal(ClientCall.Listener<RespT>, Metadata) - Method in class io.grpc.internal.ClientCallImpl
- startLbComm(List<EquivalentAddressGroup>) - Method in class io.grpc.grpclb.GrpclbState
- startLbRpc() - Method in class io.grpc.grpclb.GrpclbState
- startNewTransport() - Method in class io.grpc.internal.InternalSubchannel
- startRpc() - Method in class io.grpc.protobuf.services.HealthCheckingLoadBalancerFactory.HealthCheckState
- startServerId_ - Variable in class io.grpc.channelz.v1.GetServersRequest.Builder
- startServerId_ - Variable in class io.grpc.channelz.v1.GetServersRequest
- startSocketId_ - Variable in class io.grpc.channelz.v1.GetServerSocketsRequest.Builder
- startSocketId_ - Variable in class io.grpc.channelz.v1.GetServerSocketsRequest
- startTimeNanos - Variable in class io.grpc.internal.DelayedStream
- startWrappedCall(String, ServerImpl.ServerTransportListenerImpl.ServerCallParameters<WReqT, WRespT>, Metadata) - Method in class io.grpc.internal.ServerImpl.ServerTransportListenerImpl
- startWriteQueue(Channel) - Method in class io.grpc.netty.NettyClientHandler
- state - Variable in class io.grpc.ConnectivityStateInfo
- state - Variable in class io.grpc.grpclb.CachedSubchannelPool.CacheEntry
- state - Variable in class io.grpc.internal.ConnectivityStateManager
- state - Variable in class io.grpc.internal.GzipInflatingBuffer
- state - Variable in class io.grpc.internal.InternalSubchannel
- state - Variable in class io.grpc.internal.KeepAliveManager
- state - Variable in class io.grpc.internal.MessageDeframer
- state - Variable in class io.grpc.internal.PickFirstLeafLoadBalancer.SubchannelData
- state - Variable in class io.grpc.internal.RetriableStream
- state - Variable in class io.grpc.InternalChannelz.ChannelStats.Builder
- state - Variable in class io.grpc.InternalChannelz.ChannelStats
- state - Variable in class io.grpc.InternalChannelz.TcpInfo.Builder
- state - Variable in class io.grpc.InternalChannelz.TcpInfo
- state - Variable in class io.grpc.netty.NettyClientStream
- state - Variable in class io.grpc.netty.NettyServerStream
- state - Variable in class io.grpc.rls.CachingRlsLbClient.RlsLbHelper
- state - Variable in class io.grpc.rls.LbPolicyConfiguration.ChildPolicyWrapper
- State() - Constructor for enum io.grpc.internal.GzipInflatingBuffer.State
- State() - Constructor for enum io.grpc.internal.KeepAliveManager.State
- State() - Constructor for enum io.grpc.internal.MessageDeframer.State
- State(int) - Constructor for enum io.grpc.channelz.v1.ChannelConnectivityState.State
- State(long) - Constructor for class io.grpc.internal.AtomicBackoff.State
- State(List<RetriableStream.BufferEntry>, Collection<RetriableStream.Substream>, Collection<RetriableStream.Substream>, RetriableStream.Substream, boolean, boolean, boolean, int) - Constructor for class io.grpc.internal.RetriableStream.State
- state_ - Variable in class io.grpc.channelz.v1.ChannelConnectivityState.Builder
- state_ - Variable in class io.grpc.channelz.v1.ChannelConnectivityState
- state_ - Variable in class io.grpc.channelz.v1.ChannelData.Builder
- state_ - Variable in class io.grpc.channelz.v1.ChannelData
- STATE_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.ChannelConnectivityState
- STATE_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.ChannelData
- STATE_INFO - Static variable in class io.grpc.grpclb.GrpclbState
- stateBuilder_ - Variable in class io.grpc.channelz.v1.ChannelData.Builder
- stateListener - Variable in class io.grpc.protobuf.services.HealthCheckingLoadBalancerFactory.HealthCheckState
- stateMap - Variable in class io.grpc.rls.SubchannelStateManagerImpl
- stateMultiset - Variable in class io.grpc.rls.SubchannelStateManagerImpl
- statsEnabled - Variable in class io.grpc.internal.ManagedChannelImplBuilder
- statsEnabled - Variable in class io.grpc.internal.ServerImplBuilder
- statsTraceContext() - Method in class io.grpc.inprocess.InProcessTransport.InProcessStream.InProcessServerStream
- 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.
- StatsTraceContext(StreamTracer[]) - Constructor for class io.grpc.internal.StatsTraceContext
- statsTraceCtx - Variable in class io.grpc.inprocess.InProcessTransport.InProcessStream.InProcessClientStream
- statsTraceCtx - Variable in class io.grpc.inprocess.InProcessTransport.InProcessStream.InProcessServerStream
- statsTraceCtx - Variable in class io.grpc.internal.AbstractClientStream.GetFramer
- statsTraceCtx - Variable in class io.grpc.internal.AbstractClientStream.TransportState
-
Whether listener.closed() has been called.
- statsTraceCtx - Variable in class io.grpc.internal.AbstractServerStream
- statsTraceCtx - Variable in class io.grpc.internal.AbstractServerStream.TransportState
- statsTraceCtx - Variable in class io.grpc.internal.AbstractStream.TransportState
- statsTraceCtx - Variable in class io.grpc.internal.MessageDeframer.SizeEnforcingInputStream
- statsTraceCtx - Variable in class io.grpc.internal.MessageDeframer
- statsTraceCtx - Variable in class io.grpc.internal.MessageFramer
- status - Variable in class io.grpc.ConnectivityStateInfo
- status - Variable in class io.grpc.internal.DelayedClientCall.CloseListenerRunnable
- status - Variable in enum io.grpc.internal.GrpcUtil.Http2Error
- status - Variable in class io.grpc.internal.RetriableStream.SavedCloseMasterListenerReason
- status - Variable in class io.grpc.InternalConfigSelector.Result
- status - Variable in class io.grpc.LoadBalancer.PickResult
- status - Variable in class io.grpc.NameResolver.ConfigOrError
- status - Variable in class io.grpc.netty.ForcefulCloseCommand
- status - Variable in class io.grpc.netty.GracefulCloseCommand
- status - Variable in class io.grpc.netty.SendResponseHeadersCommand
- status - Variable in class io.grpc.rls.CachingRlsLbClient.BackoffCacheEntry
- status - Variable in exception class io.grpc.StatusException
- status - Variable in class io.grpc.StatusOr
- status - Variable in exception class io.grpc.StatusRuntimeException
- status - Variable in class io.grpc.util.MultiChildLoadBalancer.AcceptResolvedAddrRetVal
- status() - Method in enum io.grpc.internal.GrpcUtil.Http2Error
-
Gets the
Status
associated with this HTTP/2 code. - status() - Method in class io.grpc.netty.AbstractHttp2Headers
- status() - Method in class io.grpc.netty.GrpcHttp2HeadersUtils.GrpcHttp2InboundHeaders
- status() - Method in class io.grpc.netty.GrpcHttp2OutboundHeaders
- status() - Method in class io.grpc.netty.SendResponseHeadersCommand
- status(CharSequence) - Method in class io.grpc.netty.AbstractHttp2Headers
- 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(Status.Code) - Constructor for class io.grpc.Status
- Status(Status.Code, String, Throwable) - Constructor for class io.grpc.Status
- status_ - Variable in class io.grpc.health.v1.HealthCheckResponse.Builder
- status_ - Variable in class io.grpc.health.v1.HealthCheckResponse
- STATUS_CODE_FIELD_NUMBER - Static variable in class io.grpc.binarylog.v1.Trailer
- STATUS_DETAILS_FIELD_NUMBER - Static variable in class io.grpc.binarylog.v1.Trailer
- STATUS_DETAILS_KEY - Static variable in class io.grpc.protobuf.services.BinlogHelper
- STATUS_DETAILS_KEY - Static variable in class io.grpc.protobuf.StatusProto
- STATUS_FIELD_NUMBER - Static variable in class io.grpc.health.v1.HealthCheckResponse
- STATUS_LIST - Static variable in class io.grpc.Status
- STATUS_MESSAGE_FIELD_NUMBER - Static variable in class io.grpc.binarylog.v1.Trailer
- STATUS_MESSAGE_MARSHALLER - Static variable in class io.grpc.Status
-
Marshals status messages for (
Status.MESSAGE_KEY
. - STATUS_OK - Static variable in class io.grpc.netty.Utils
- Status.Code - Enum in io.grpc
-
The set of canonical status codes.
- Status.StatusCodeMarshaller - Class in io.grpc
- Status.StatusMessageMarshaller - Class in io.grpc
- statusCode_ - Variable in class io.grpc.binarylog.v1.Trailer.Builder
- statusCode_ - Variable in class io.grpc.binarylog.v1.Trailer
- StatusCodeMarshaller() - Constructor for class io.grpc.Status.StatusCodeMarshaller
- statusDetails_ - Variable in class io.grpc.binarylog.v1.Trailer.Builder
- statusDetails_ - Variable in class io.grpc.binarylog.v1.Trailer
- StatusException - Exception Class in io.grpc
-
Status
in Exception form, for propagating Status information via exceptions. - StatusException(Status) - Constructor for exception class io.grpc.StatusException
-
Constructs an exception with both a status.
- StatusException(Status, Metadata) - Constructor for exception class io.grpc.StatusException
-
Constructs an exception with both a status and trailers.
- StatusException(Status, Metadata, boolean) - Constructor for exception class io.grpc.StatusException
- statusExplainingWhyTheChannelIsNull - Variable in class io.grpc.netty.NettyClientTransport
-
If
NettyClientTransport.start(io.grpc.internal.ManagedClientTransport.Listener)
has been called, non-null
if channel isnull
. - 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 ornull
if the context is not cancelled. - statusFromFailedFuture(ChannelFuture) - Method in class io.grpc.netty.NettyClientStream.TransportState
-
Intended to be overridden by NettyClientTransport, which has more information about failures.
- statusFromFailedFuture(ChannelFuture) - Method in class io.grpc.netty.NettyClientTransport
-
Convert ChannelFuture.cause() to a Status, taking into account that all handlers are removed from the pipeline when the channel is closed.
- statusFromH2Error(Status.Code, String, long, byte[]) - Method in class io.grpc.netty.NettyClientHandler
-
If
statusCode
is non-null, it will be used instead of the http2 error code mapping. - statusFromThrowable(Throwable) - Static method in class io.grpc.netty.Utils
- statusFromTrailers(Metadata) - Method in class io.grpc.internal.Http2ClientStreamTransportState
-
Extract the response status from trailers.
- statusMap - Variable in class io.grpc.protobuf.services.HealthServiceImpl
- statusMessage_ - Variable in class io.grpc.binarylog.v1.Trailer.Builder
- statusMessage_ - Variable in class io.grpc.binarylog.v1.Trailer
- StatusMessageMarshaller() - Constructor for class io.grpc.Status.StatusMessageMarshaller
- StatusOr<T> - Class in io.grpc
-
Either a Status or a value.
- StatusOr(Status, T) - Constructor for class io.grpc.StatusOr
- StatusProto - Class in io.grpc.protobuf
-
Utility methods for working with
Status
. - StatusProto() - Constructor for class io.grpc.protobuf.StatusProto
- statusReported - Variable in class io.grpc.internal.AbstractClientStream.TransportState
-
Whether the stream is closed from the transport's perspective.
- statusReportedIsOk - Variable in class io.grpc.internal.AbstractClientStream.TransportState
-
True if the status reported (set via
AbstractClientStream.TransportState.transportReportStatus(io.grpc.Status, boolean, io.grpc.Metadata)
) is OK. - StatusRuntimeException - Exception Class in io.grpc
-
Status
in RuntimeException form, for propagating Status information via exceptions. - StatusRuntimeException(Status) - Constructor for exception class io.grpc.StatusRuntimeException
-
Constructs the exception with a status.
- StatusRuntimeException(Status, Metadata) - Constructor for exception class io.grpc.StatusRuntimeException
-
Constructs the exception with both a status and trailers.
- StatusRuntimeException(Status, Metadata, boolean) - Constructor for exception class io.grpc.StatusRuntimeException
- stdevFactor - Variable in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig.SuccessRateEjection.Builder
- stdevFactor - Variable in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig.SuccessRateEjection
- stopDelivery - Variable in class io.grpc.internal.MessageDeframer
- stopDelivery() - Method in class io.grpc.internal.MessageDeframer
-
Sets a flag to interrupt delivery of any currently queued messages.
- STOPPED - Static variable in class io.grpc.internal.SerializingExecutor
- stopRpc(String) - Method in class io.grpc.protobuf.services.HealthCheckingLoadBalancerFactory.HealthCheckState
- stopwatch - Variable in class io.grpc.grpclb.GrpclbLoadBalancer
- stopwatch - Variable in class io.grpc.grpclb.GrpclbState
- stopwatch - Variable in class io.grpc.internal.DnsNameResolver
- stopwatch - Variable in class io.grpc.internal.Http2Ping
-
Used to measure elapsed time.
- stopwatch - Variable in class io.grpc.internal.KeepAliveManager
- stopwatch - Variable in class io.grpc.internal.Rescheduler
- stopwatch - Variable in class io.grpc.protobuf.services.HealthCheckingLoadBalancerFactory.HealthCheckState.HcStream
- STOPWATCH_SUPPLIER - Static variable in class io.grpc.internal.GrpcUtil
-
The factory of default Stopwatches.
- stopwatchFactory - Variable in class io.grpc.netty.NettyClientHandler
- stopwatchSupplier - Variable in class io.grpc.internal.ManagedChannelImpl
- stopwatchSupplier - Variable in class io.grpc.protobuf.services.HealthCheckingLoadBalancerFactory
- storage - Static variable in class io.grpc.Context.LazyStorage
- storage() - Static method in class io.grpc.Context
- Storage() - Constructor for class io.grpc.Context.Storage
- storedListener - Variable in class io.grpc.internal.ApplicationThreadDeframer
- storedListener - Variable in class io.grpc.internal.ApplicationThreadDeframerListener
- stream - Variable in class io.grpc.grpclb.GrpclbState.LoadReportingTask
- stream - Variable in class io.grpc.internal.ClientCallImpl
- stream - Variable in class io.grpc.internal.RetriableStream.Substream
- stream - Variable in class io.grpc.internal.ServerCallImpl
- stream - Variable in class io.grpc.internal.ServerImpl.JumpToApplicationThreadServerStreamListener
- stream - Variable in class io.grpc.netty.CancelClientStreamCommand
- stream - Variable in class io.grpc.netty.CancelServerStreamCommand
- stream - Variable in class io.grpc.netty.CreateStreamCommand
- stream - Variable in class io.grpc.netty.SendGrpcFrameCommand
- stream - Variable in class io.grpc.netty.SendResponseHeadersCommand
- stream - Variable in class io.grpc.servlet.jakarta.ServletAdapter.GrpcAsyncListener
- stream - Variable in class io.grpc.servlet.jakarta.ServletAdapter.GrpcReadListener
- stream - Variable in class io.grpc.servlet.ServletAdapter.GrpcAsyncListener
- stream - Variable in class io.grpc.servlet.ServletAdapter.GrpcReadListener
- stream() - Method in class io.grpc.netty.CancelClientStreamCommand
- stream() - Method in class io.grpc.netty.CancelServerStreamCommand
- stream() - Method in class io.grpc.netty.CreateStreamCommand
- stream() - Method in class io.grpc.netty.SendGrpcFrameCommand
- stream() - Method in class io.grpc.netty.SendResponseHeadersCommand
- stream(byte[]) - Method in class io.grpc.protobuf.services.BinaryLogProvider.ByteArrayMarshaller
- 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. - stream(T) - Method in class io.grpc.protobuf.lite.ProtoLiteUtils.MessageMarshaller
- Stream - Interface in io.grpc.internal
-
A single stream of communication between two end-points within a transport.
- STREAM_CLOSED - Enum constant in enum io.grpc.internal.GrpcUtil.Http2Error
- STREAM_OP - Static variable in class io.grpc.internal.CompositeReadableBuffer
- streamClosed() - Method in class io.grpc.inprocess.InProcessTransport.InProcessStream
- streamClosed(Status) - Method in class io.grpc.grpclb.GrpclbClientLoadRecorder.StreamTracer
- streamClosed(Status) - Method in class io.grpc.internal.ForwardingClientStreamTracer
- streamClosed(Status) - Method in class io.grpc.internal.StatsTraceContext
- streamClosed(Status) - Method in class io.grpc.StreamTracer
-
Stream is closed.
- streamClosed(Status) - Method in class io.grpc.util.ForwardingClientStreamTracer
- streamCreated(Attributes, Metadata) - Method in class io.grpc.ClientStreamTracer
-
The stream is being created on a ready transport.
- streamCreated(Attributes, Metadata) - Method in class io.grpc.internal.ForwardingClientStreamTracer
- streamCreated(Attributes, Metadata) - Method in class io.grpc.util.ForwardingClientStreamTracer
- streamCreated(ServerStream, String, Metadata) - Method in class io.grpc.internal.ServerImpl.ServerTransportListenerImpl
- streamCreated(ServerStream, String, Metadata) - Method in interface io.grpc.internal.ServerTransportListener
-
Called when a new stream was created by the remote client.
- streamCreatedInternal(ServerStream, String, Metadata, Tag) - Method in class io.grpc.internal.ServerImpl.ServerTransportListenerImpl
- streamGone(int, ChannelPromise) - Static method in class io.grpc.netty.NettyServerHandler
- streamId - Variable in class io.grpc.netty.NettyServerStream
- streamId() - Method in class io.grpc.inprocess.InProcessTransport.InProcessStream.InProcessServerStream
- streamId() - Method in interface io.grpc.internal.ServerStream
-
The HTTP/2 stream id, or
-1
if not supported. - streamId() - Method in class io.grpc.netty.NettyServerStream
- streamId() - Method in class io.grpc.servlet.jakarta.ServletServerStream
- streamId() - Method in class io.grpc.servlet.ServletServerStream
- StreamIdHolder - Interface in io.grpc.netty
-
Container for stream ids.
- StreamInfo(CallOptions, int, boolean) - Constructor for class io.grpc.ClientStreamTracer.StreamInfo
- streamingResponse - Variable in class io.grpc.stub.ClientCalls.CallToStreamObserverAdapter
- StreamingServerCallHandler(ServerCalls.StreamingRequestMethod<ReqT, RespT>, boolean) - Constructor for class io.grpc.stub.ServerCalls.StreamingServerCallHandler
- StreamingServerCallListener(StreamObserver<ReqT>, ServerCalls.ServerCallStreamObserverImpl<ReqT, RespT>, ServerCall<ReqT, RespT>) - Constructor for class io.grpc.stub.ServerCalls.StreamingServerCallHandler.StreamingServerCallListener
- streamKey - Variable in class io.grpc.netty.NettyClientHandler
- streamKey - Variable in class io.grpc.netty.NettyServerHandler
- StreamListener - Interface in io.grpc.internal
-
An observer of
Stream
events. - StreamListener.MessageProducer - Interface in io.grpc.internal
-
A producer for deframed gRPC messages.
- StreamObserver<V> - Interface in io.grpc.stub
-
Receives notifications from an observable stream of messages.
- StreamObservers - Class in io.grpc.stub
-
Deprecated.Of questionable utility and generally not used.
- StreamObservers() - Constructor for class io.grpc.stub.StreamObservers
-
Deprecated.
- StreamObserverToCallListenerAdapter(StreamObserver<RespT>, ClientCalls.CallToStreamObserverAdapter<ReqT>) - Constructor for class io.grpc.stub.ClientCalls.StreamObserverToCallListenerAdapter
- streamRequest(ReqT) - Method in class io.grpc.MethodDescriptor
-
Convert a request message to an
InputStream
. - streamResponse(RespT) - Method in class io.grpc.MethodDescriptor
-
Serialize an outgoing response message.
- streams - Variable in class io.grpc.inprocess.InProcessTransport
- STREAMS_FAILED_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.SocketData
- STREAMS_STARTED_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.SocketData
- STREAMS_SUCCEEDED_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.SocketData
- streamSetTimeNanos - Variable in class io.grpc.internal.DelayedStream
- streamsFailed - Variable in class io.grpc.internal.TransportTracer
- streamsFailed - Variable in class io.grpc.InternalChannelz.TransportStats
- streamsFailed_ - Variable in class io.grpc.channelz.v1.SocketData.Builder
- streamsFailed_ - Variable in class io.grpc.channelz.v1.SocketData
- streamsStarted - Variable in class io.grpc.internal.TransportTracer
- streamsStarted - Variable in class io.grpc.InternalChannelz.TransportStats
- streamsStarted_ - Variable in class io.grpc.channelz.v1.SocketData.Builder
- streamsStarted_ - Variable in class io.grpc.channelz.v1.SocketData
- streamsSucceeded - Variable in class io.grpc.internal.TransportTracer
- streamsSucceeded - Variable in class io.grpc.InternalChannelz.TransportStats
- streamsSucceeded_ - Variable in class io.grpc.channelz.v1.SocketData.Builder
- streamsSucceeded_ - Variable in class io.grpc.channelz.v1.SocketData
- streamToBytes(InputStream) - Static method in class io.grpc.Metadata
- StreamTracer - Class in io.grpc
-
Listens to events on a stream to collect metrics.
- StreamTracer() - Constructor for class io.grpc.grpclb.GrpclbClientLoadRecorder.StreamTracer
- StreamTracer() - Constructor for class io.grpc.StreamTracer
- streamTracerFactories - Variable in class io.grpc.CallOptions.Builder
- streamTracerFactories - Variable in class io.grpc.CallOptions
- streamTracerFactories - Variable in class io.grpc.inprocess.InProcessServer
- streamTracerFactories - Variable in class io.grpc.internal.ServerImplBuilder
- streamTracerFactories - Variable in class io.grpc.netty.NettyServer
- streamTracerFactories - Variable in class io.grpc.netty.NettyServerHandler
- streamTracerFactories - Variable in class io.grpc.netty.NettyServerTransport
- streamTracerFactories - Variable in class io.grpc.servlet.jakarta.ServletAdapter
- streamTracerFactories - Variable in class io.grpc.servlet.jakarta.ServletServerBuilder
- streamTracerFactories - Variable in class io.grpc.servlet.ServletAdapter
- streamTracerFactories - Variable in class io.grpc.servlet.ServletServerBuilder
- streamTracerFactory - Variable in class io.grpc.LoadBalancer.PickResult
- STRING_OVERHEAD_BYTES - Static variable in class io.grpc.rls.CachingRlsLbClient
- stripOverrideAuthorityAttributes(List<EquivalentAddressGroup>) - Method in class io.grpc.internal.ManagedChannelImpl.SubchannelImpl
- stripTransportDetails(Metadata) - Static method in class io.grpc.internal.Http2ClientStreamTransportState
-
Strip HTTP transport implementation details so they don't leak via metadata into the application layer.
- stub - Variable in class io.grpc.grpclb.GrpclbState.LbStream
- STUB_TYPE_OPTION - Static variable in class io.grpc.stub.ClientCalls
-
Internal
CallOptions.Key
to indicate stub types. - StubType() - Constructor for enum io.grpc.stub.ClientCalls.StubType
- StubType(ClientCalls.StubType) - Constructor for enum io.grpc.stub.InternalClientCalls.StubType
- SUB_DELIMS - Static variable in class io.grpc.internal.GrpcUtil.AuthorityEscaper
- subchannel - Variable in class io.grpc.grpclb.CachedSubchannelPool.CacheEntry
- subchannel - Variable in class io.grpc.grpclb.CachedSubchannelPool.ShutdownSubchannelTask
- subchannel - Variable in class io.grpc.grpclb.GrpclbState.BackendEntry
- subchannel - Variable in class io.grpc.grpclb.GrpclbState.IdleSubchannelEntry
- subchannel - Variable in class io.grpc.internal.ManagedChannelImpl.SubchannelImpl
- subchannel - Variable in class io.grpc.internal.OobChannel
- subchannel - Variable in class io.grpc.internal.PickFirstLeafLoadBalancer.SubchannelData
- subchannel - Variable in class io.grpc.internal.PickFirstLoadBalancer.RequestConnectionPicker
- subchannel - Variable in class io.grpc.internal.PickFirstLoadBalancer
- subchannel - Variable in class io.grpc.internal.SubchannelChannel
- subchannel - Variable in class io.grpc.LoadBalancer.PickResult
- subchannel - Variable in class io.grpc.protobuf.services.HealthCheckingLoadBalancerFactory.HealthCheckState
- Subchannel - Class in io.grpc.channelz.v1
-
Subchannel is a logical grouping of channels, subchannels, and sockets.
- Subchannel() - Constructor for class io.grpc.channelz.v1.Subchannel
- Subchannel() - Constructor for class io.grpc.LoadBalancer.Subchannel
- Subchannel(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.channelz.v1.Subchannel
- subchannel_ - Variable in class io.grpc.channelz.v1.GetSubchannelResponse.Builder
- subchannel_ - Variable in class io.grpc.channelz.v1.GetSubchannelResponse
- SUBCHANNEL_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.GetSubchannelResponse
- SUBCHANNEL_ID_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.GetSubchannelRequest
- SUBCHANNEL_ID_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.SubchannelRef
- SUBCHANNEL_REF - Enum constant in enum io.grpc.channelz.v1.ChannelTraceEvent.ChildRefCase
- SUBCHANNEL_REF_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.Channel
- SUBCHANNEL_REF_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.ChannelTraceEvent
- SUBCHANNEL_REF_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.Subchannel
- SUBCHANNEL_SHUTDOWN_DELAY_SECONDS - Static variable in class io.grpc.internal.ManagedChannelImpl
- SUBCHANNEL_SHUTDOWN_STATUS - Static variable in class io.grpc.internal.ManagedChannelImpl
- Subchannel.Builder - Class in io.grpc.channelz.v1
-
Subchannel is a logical grouping of channels, subchannels, and sockets.
- subchannelBuilder_ - Variable in class io.grpc.channelz.v1.GetSubchannelResponse.Builder
- SubchannelChannel - Class in io.grpc.internal
- SubchannelChannel(InternalSubchannel, Executor, ScheduledExecutorService, CallTracer, AtomicReference<InternalConfigSelector>) - Constructor for class io.grpc.internal.SubchannelChannel
- subchannelData - Variable in class io.grpc.internal.PickFirstLeafLoadBalancer.HealthListener
- SubchannelData(LoadBalancer.Subchannel, ConnectivityState) - Constructor for class io.grpc.internal.PickFirstLeafLoadBalancer.SubchannelData
- subchannelId_ - Variable in class io.grpc.channelz.v1.GetSubchannelRequest.Builder
- subchannelId_ - Variable in class io.grpc.channelz.v1.GetSubchannelRequest
- subchannelId_ - Variable in class io.grpc.channelz.v1.SubchannelRef.Builder
- subchannelId_ - Variable in class io.grpc.channelz.v1.SubchannelRef
- subchannelImpl - Variable in class io.grpc.internal.OobChannel
- SubchannelImpl(LoadBalancer.CreateSubchannelArgs) - Constructor for class io.grpc.internal.ManagedChannelImpl.SubchannelImpl
- SubchannelImpl(LoadBalancer.Subchannel, HealthCheckingLoadBalancerFactory.HealthCheckState) - Constructor for class io.grpc.protobuf.services.HealthCheckingLoadBalancerFactory.SubchannelImpl
- subchannelLogger - Variable in class io.grpc.internal.ManagedChannelImpl.SubchannelImpl
- subchannelLogger - Variable in class io.grpc.protobuf.services.HealthCheckingLoadBalancerFactory.HealthCheckState
- subchannelLogId - Variable in class io.grpc.internal.ManagedChannelImpl.SubchannelImpl
- SubchannelOrBuilder - Interface in io.grpc.channelz.v1
- subchannelPicker - Variable in class io.grpc.internal.ManagedChannelImpl
- subchannelPicker - Variable in class io.grpc.internal.OobChannel
- SubchannelPicker() - Constructor for class io.grpc.LoadBalancer.SubchannelPicker
- subchannelPickers - Variable in class io.grpc.util.RoundRobinLoadBalancer.ReadyPicker
- subchannelPool - Variable in class io.grpc.grpclb.GrpclbLoadBalancer
- subchannelPool - Variable in class io.grpc.grpclb.GrpclbState
- SubchannelPool - Interface in io.grpc.grpclb
-
Manages life-cycle of Subchannels for
GrpclbState
. - SubchannelPool.PooledSubchannelStateListener - Interface in io.grpc.grpclb
-
Receives state changes for a pooled
LoadBalancer.Subchannel
. - subchannelRef - Variable in class io.grpc.InternalChannelz.ChannelTrace.Event.Builder
- subchannelRef - Variable in class io.grpc.InternalChannelz.ChannelTrace.Event
- SubchannelRef - Class in io.grpc.channelz.v1
-
SubchannelRef is a reference to a Subchannel.
- SubchannelRef() - Constructor for class io.grpc.channelz.v1.SubchannelRef
- SubchannelRef(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.channelz.v1.SubchannelRef
- subchannelRef_ - Variable in class io.grpc.channelz.v1.Channel.Builder
- subchannelRef_ - Variable in class io.grpc.channelz.v1.Channel
- subchannelRef_ - Variable in class io.grpc.channelz.v1.Subchannel.Builder
- subchannelRef_ - Variable in class io.grpc.channelz.v1.Subchannel
- SubchannelRef.Builder - Class in io.grpc.channelz.v1
-
SubchannelRef is a reference to a Subchannel.
- subchannelRefBuilder_ - Variable in class io.grpc.channelz.v1.Channel.Builder
- subchannelRefBuilder_ - Variable in class io.grpc.channelz.v1.ChannelTraceEvent.Builder
- subchannelRefBuilder_ - Variable in class io.grpc.channelz.v1.Subchannel.Builder
- SubchannelRefOrBuilder - Interface in io.grpc.channelz.v1
- subchannels - Variable in class io.grpc.grpclb.GrpclbState
- subchannels - Variable in class io.grpc.internal.ManagedChannelImpl
- subchannels - Variable in class io.grpc.internal.PickFirstLeafLoadBalancer
- subchannels - Variable in class io.grpc.InternalChannelz.ChannelStats.Builder
- subchannels - Variable in class io.grpc.InternalChannelz.ChannelStats
- subchannels - Variable in class io.grpc.InternalChannelz
- subchannels - Variable in class io.grpc.util.OutlierDetectionLoadBalancer.EndpointTracker
- subchannelsEjected() - Method in class io.grpc.util.OutlierDetectionLoadBalancer.EndpointTracker
- subchannelStateListener - Variable in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionSubchannel
- subchannelStateManager - Variable in class io.grpc.rls.ChildLoadBalancerHelper.ChildLoadBalancerHelperProvider
- subchannelStateManager - Variable in class io.grpc.rls.ChildLoadBalancerHelper
- SubchannelStateManager - Interface in io.grpc.rls
-
SubchannelStateManager manages
ConnectivityState
of child subchannels. - SubchannelStateManagerImpl - Class in io.grpc.rls
-
Implementation of
SubchannelStateManager
. - SubchannelStateManagerImpl() - Constructor for class io.grpc.rls.SubchannelStateManagerImpl
- subchannelTracer - Variable in class io.grpc.internal.ManagedChannelImpl.SubchannelImpl
- Sublistener(RetriableStream.Substream) - Constructor for class io.grpc.internal.RetriableStream.Sublistener
- submit(Runnable) - Method in class io.grpc.internal.ManagedChannelImpl.RestrictedScheduledExecutor
- submit(Runnable, T) - Method in class io.grpc.internal.ManagedChannelImpl.RestrictedScheduledExecutor
- submit(Callable<T>) - Method in class io.grpc.internal.ManagedChannelImpl.RestrictedScheduledExecutor
- substream - Variable in class io.grpc.internal.RetriableStream.BufferSizeTracer
- substream - Variable in class io.grpc.internal.RetriableStream.Sublistener
- Substream(int) - Constructor for class io.grpc.internal.RetriableStream.Substream
- substreamClosed(RetriableStream.Substream) - Method in class io.grpc.internal.RetriableStream.State
-
The given substream is closed.
- substreamDrained(RetriableStream.Substream) - Method in class io.grpc.internal.RetriableStream.State
-
The given substream is drained.
- success - Variable in class io.grpc.util.AdvancedTlsX509KeyManager.UpdateResult
- SUCCESS - Enum constant in enum io.grpc.internal.ManagedChannelImpl.ResolutionState
- successCount - Variable in class io.grpc.util.OutlierDetectionLoadBalancer.EndpointTracker.CallCounter
- successRate() - Method in class io.grpc.util.OutlierDetectionLoadBalancer.EndpointTracker
- successRateEjection - Variable in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig.Builder
- successRateEjection - Variable in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig
- SuccessRateEjection(Integer, Integer, Integer, Integer) - Constructor for class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig.SuccessRateEjection
- SuccessRateOutlierEjectionAlgorithm(OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig, ChannelLogger) - Constructor for class io.grpc.util.OutlierDetectionLoadBalancer.SuccessRateOutlierEjectionAlgorithm
- summary_ - Variable in class io.grpc.channelz.v1.GetSocketRequest.Builder
- summary_ - Variable in class io.grpc.channelz.v1.GetSocketRequest
- SUMMARY_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.GetSocketRequest
- sumMethod - Static variable in class io.grpc.internal.ReflectionLongAdderCounter
- SUN_PROVIDER_NAME - Static variable in class io.grpc.netty.GrpcSslContexts
- swap() - Method in class io.grpc.util.GracefulSwitchLoadBalancer
- swapChannelCredentials(ChannelCredentials) - Method in class io.grpc.inprocess.InProcessChannelBuilder.InProcessClientTransportFactory
- swapChannelCredentials(ChannelCredentials) - Method in class io.grpc.internal.CallCredentialsApplyingTransportFactory
- swapChannelCredentials(ChannelCredentials) - Method in interface io.grpc.internal.ClientTransportFactory
-
Swaps to a new ChannelCredentials with all other settings unchanged.
- swapChannelCredentials(ChannelCredentials) - Method in class io.grpc.netty.NettyChannelBuilder.NettyTransportFactory
- SwapChannelCredentialsResult(ClientTransportFactory, CallCredentials) - Constructor for class io.grpc.internal.ClientTransportFactory.SwapChannelCredentialsResult
- swapCounters() - Method in class io.grpc.util.OutlierDetectionLoadBalancer.EndpointTracker
-
Swaps the active and inactive counters.
- swapCounters() - Method in class io.grpc.util.OutlierDetectionLoadBalancer.EndpointTrackerMap
-
Swaps the active and inactive counters for each tracker.
- switchLb - Variable in class io.grpc.util.OutlierDetectionLoadBalancer
- switchTo(LoadBalancer.Factory) - Method in class io.grpc.util.GracefulSwitchLoadBalancer
-
Deprecated.Use
parseLoadBalancingPolicyConfig()
and pass the configuration toLoadBalancer.ResolvedAddresses.Builder.setLoadBalancingPolicyConfig(java.lang.Object)
- switchToCalled - Variable in class io.grpc.util.GracefulSwitchLoadBalancer
- switchToInternal(LoadBalancer.Factory) - Method in class io.grpc.util.GracefulSwitchLoadBalancer
- syncContext - Variable in class io.grpc.grpclb.GrpclbState.IdleSubchannelEntry
- syncContext - Variable in class io.grpc.grpclb.GrpclbState
- syncContext - Variable in class io.grpc.inprocess.InProcessTransport.InProcessStream.InProcessClientStream
- syncContext - Variable in class io.grpc.inprocess.InProcessTransport.InProcessStream.InProcessServerStream
- syncContext - Variable in class io.grpc.internal.BackoffPolicyRetryScheduler
- syncContext - Variable in class io.grpc.internal.DelayedClientTransport
- syncContext - Variable in class io.grpc.internal.DnsNameResolver
- syncContext - Variable in class io.grpc.internal.InternalSubchannel
-
All field must be mutated in the syncContext.
- syncContext - Variable in class io.grpc.internal.ManagedChannelImpl
- syncContext - Variable in class io.grpc.internal.RetryingNameResolver
- syncContext - Variable in class io.grpc.NameResolver.Args.Builder
- syncContext - Variable in class io.grpc.NameResolver.Args
- syncContext - Variable in class io.grpc.protobuf.services.HealthCheckingLoadBalancerFactory.HealthCheckState
- syncContext - Variable in class io.grpc.protobuf.services.HealthCheckingLoadBalancerFactory.HelperImpl
- syncContext - Variable in class io.grpc.util.OutlierDetectionLoadBalancer
- SynchronizationContext - Class in io.grpc
-
A synchronization context is a queue of tasks that run in sequence.
- SynchronizationContext(Thread.UncaughtExceptionHandler) - Constructor for class io.grpc.SynchronizationContext
-
Creates a SynchronizationContext.
- SynchronizationContext.ManagedRunnable - Class in io.grpc
- SynchronizationContext.ScheduledHandle - Class in io.grpc
-
Allows the user to check the status and/or cancel a task scheduled by
SynchronizationContext.schedule(java.lang.Runnable, long, java.util.concurrent.TimeUnit, java.util.concurrent.ScheduledExecutorService)
. - SynchronizedAtomicHelper() - Constructor for class io.grpc.internal.SerializingExecutor.SynchronizedAtomicHelper
- SYSTEM_TICKER - Static variable in class io.grpc.Deadline
- SYSTEM_TIME_PROVIDER - Static variable in interface io.grpc.internal.TimeProvider
- SYSTEM_TIME_PROVIDER - Static variable in interface io.grpc.protobuf.services.BinlogHelper.TimeProvider
- systemTicker - Static variable in class io.grpc.internal.MaxConnectionIdleManager
- SystemTicker() - Constructor for class io.grpc.Deadline.SystemTicker
- SystemTicker() - Constructor for class io.grpc.internal.KeepAliveEnforcer.SystemTicker
T
- tag - Variable in class io.grpc.internal.ClientCallImpl
- tag - Variable in class io.grpc.internal.ServerCallImpl
- tag - Variable in class io.grpc.internal.ServerImpl.JumpToApplicationThreadServerStreamListener
- tag - Variable in class io.grpc.netty.NettyClientStream.TransportState
- tag - Variable in class io.grpc.netty.NettyServerStream.TransportState
- tag() - Method in class io.grpc.netty.NettyClientStream.TransportState
- tag() - Method in class io.grpc.netty.NettyServerStream.TransportState
- tag() - Method in interface io.grpc.netty.StreamIdHolder
- takeOrCreateSubchannel(EquivalentAddressGroup, Attributes) - Method in class io.grpc.grpclb.CachedSubchannelPool
- takeOrCreateSubchannel(EquivalentAddressGroup, Attributes) - Method in interface io.grpc.grpclb.SubchannelPool
-
Takes a
LoadBalancer.Subchannel
from the pool for the giveneag
if there is one available. - target - Variable in class io.grpc.internal.ManagedChannelImpl
- target - Variable in class io.grpc.internal.ManagedChannelImplBuilder
- target - Variable in class io.grpc.InternalChannelz.ChannelStats.Builder
- target - Variable in class io.grpc.InternalChannelz.ChannelStats
- target - Variable in class io.grpc.rls.ChildLoadBalancerHelper
- target - Variable in class io.grpc.rls.LbPolicyConfiguration.ChildPolicyWrapper
- target - Variable in class io.grpc.rls.RlsRequestFactory
- target_ - Variable in class io.grpc.channelz.v1.ChannelData.Builder
- target_ - Variable in class io.grpc.channelz.v1.ChannelData
- TARGET_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.ChannelData
- TARGET_PICKS_COUNTER - Static variable in class io.grpc.rls.CachingRlsLbClient
- TARGET_TYPE_FIELD_NUMBER - Static variable in class io.grpc.lookup.v1.RouteLookupRequest
- targetAddress - Variable in class io.grpc.HttpConnectProxiedSocketAddress.Builder
- targetAddress - Variable in class io.grpc.HttpConnectProxiedSocketAddress
- targetFieldName - Variable in class io.grpc.rls.LbPolicyConfiguration.ChildLoadBalancingPolicy
- targets - Variable in class io.grpc.rls.AutoValue_RlsProtoData_RouteLookupResponse
- targets() - Method in class io.grpc.rls.AutoValue_RlsProtoData_RouteLookupResponse
- targets() - Method in class io.grpc.rls.RlsProtoData.RouteLookupResponse
-
Returns list of targets.
- targets_ - Variable in class io.grpc.lookup.v1.RouteLookupResponse.Builder
- targets_ - Variable in class io.grpc.lookup.v1.RouteLookupResponse
- TARGETS_FIELD_NUMBER - Static variable in class io.grpc.lookup.v1.RouteLookupResponse
- targetType_ - Variable in class io.grpc.lookup.v1.RouteLookupRequest.Builder
- targetType_ - Variable in class io.grpc.lookup.v1.RouteLookupRequest
- targetUri - Variable in class io.grpc.internal.ManagedChannelImpl
- targetUri - Variable in class io.grpc.internal.ManagedChannelImplBuilder.ResolvedNameResolver
- task - Variable in class io.grpc.internal.LogExceptionRunnable
- task - Variable in class io.grpc.SynchronizationContext.ManagedRunnable
- taskQueue - Variable in class io.grpc.internal.SerializeReentrantCallsDirectExecutor
- TCP_INFO - Static variable in class io.grpc.protobuf.services.ChannelzProtoUtil
- TCPI_ADVMSS_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.SocketOptionTcpInfo
- TCPI_ATO_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.SocketOptionTcpInfo
- TCPI_BACKOFF_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.SocketOptionTcpInfo
- TCPI_CA_STATE_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.SocketOptionTcpInfo
- TCPI_FACKETS_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.SocketOptionTcpInfo
- TCPI_LAST_ACK_RECV_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.SocketOptionTcpInfo
- TCPI_LAST_ACK_SENT_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.SocketOptionTcpInfo
- TCPI_LAST_DATA_RECV_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.SocketOptionTcpInfo
- TCPI_LAST_DATA_SENT_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.SocketOptionTcpInfo
- TCPI_LOST_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.SocketOptionTcpInfo
- TCPI_OPTIONS_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.SocketOptionTcpInfo
- TCPI_PMTU_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.SocketOptionTcpInfo
- TCPI_PROBES_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.SocketOptionTcpInfo
- TCPI_RCV_MSS_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.SocketOptionTcpInfo
- TCPI_RCV_SSTHRESH_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.SocketOptionTcpInfo
- TCPI_RCV_WSCALE_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.SocketOptionTcpInfo
- TCPI_REORDERING_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.SocketOptionTcpInfo
- TCPI_RETRANS_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.SocketOptionTcpInfo
- TCPI_RETRANSMITS_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.SocketOptionTcpInfo
- TCPI_RTO_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.SocketOptionTcpInfo
- TCPI_RTT_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.SocketOptionTcpInfo
- TCPI_RTTVAR_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.SocketOptionTcpInfo
- TCPI_SACKED_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.SocketOptionTcpInfo
- TCPI_SND_CWND_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.SocketOptionTcpInfo
- TCPI_SND_MSS_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.SocketOptionTcpInfo
- TCPI_SND_SSTHRESH_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.SocketOptionTcpInfo
- TCPI_SND_WSCALE_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.SocketOptionTcpInfo
- TCPI_STATE_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.SocketOptionTcpInfo
- TCPI_UNACKED_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.SocketOptionTcpInfo
- tcpiAdvmss_ - Variable in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
- tcpiAdvmss_ - Variable in class io.grpc.channelz.v1.SocketOptionTcpInfo
- tcpiAto_ - Variable in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
- tcpiAto_ - Variable in class io.grpc.channelz.v1.SocketOptionTcpInfo
- tcpiBackoff_ - Variable in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
- tcpiBackoff_ - Variable in class io.grpc.channelz.v1.SocketOptionTcpInfo
- tcpiCaState_ - Variable in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
- tcpiCaState_ - Variable in class io.grpc.channelz.v1.SocketOptionTcpInfo
- tcpiFackets_ - Variable in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
- tcpiFackets_ - Variable in class io.grpc.channelz.v1.SocketOptionTcpInfo
- tcpiLastAckRecv_ - Variable in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
- tcpiLastAckRecv_ - Variable in class io.grpc.channelz.v1.SocketOptionTcpInfo
- tcpiLastAckSent_ - Variable in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
- tcpiLastAckSent_ - Variable in class io.grpc.channelz.v1.SocketOptionTcpInfo
- tcpiLastDataRecv_ - Variable in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
- tcpiLastDataRecv_ - Variable in class io.grpc.channelz.v1.SocketOptionTcpInfo
- tcpiLastDataSent_ - Variable in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
- tcpiLastDataSent_ - Variable in class io.grpc.channelz.v1.SocketOptionTcpInfo
- tcpiLost_ - Variable in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
- tcpiLost_ - Variable in class io.grpc.channelz.v1.SocketOptionTcpInfo
- tcpInfo - Variable in class io.grpc.InternalChannelz.SocketOptions.Builder
- tcpInfo - Variable in class io.grpc.InternalChannelz.SocketOptions
- tcpInfo - Variable in class io.grpc.netty.NettySocketSupport.NativeSocketOptions
- TcpInfo(int, int, int, int, int, int, int, int, int, int, int, int, int, int, int, int, int, int, int, int, int, int, int, int, int, int, int, int, int) - Constructor for class io.grpc.InternalChannelz.TcpInfo
- tcpiOptions_ - Variable in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
- tcpiOptions_ - Variable in class io.grpc.channelz.v1.SocketOptionTcpInfo
- TCPIP_ADDRESS - Enum constant in enum io.grpc.channelz.v1.Address.AddressCase
- TCPIP_ADDRESS_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.Address
- TcpIpAddress() - Constructor for class io.grpc.channelz.v1.Address.TcpIpAddress
- TcpIpAddress(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.channelz.v1.Address.TcpIpAddress
- tcpipAddressBuilder_ - Variable in class io.grpc.channelz.v1.Address.Builder
- tcpiPmtu_ - Variable in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
- tcpiPmtu_ - Variable in class io.grpc.channelz.v1.SocketOptionTcpInfo
- tcpiProbes_ - Variable in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
- tcpiProbes_ - Variable in class io.grpc.channelz.v1.SocketOptionTcpInfo
- tcpiRcvMss_ - Variable in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
- tcpiRcvMss_ - Variable in class io.grpc.channelz.v1.SocketOptionTcpInfo
- tcpiRcvSsthresh_ - Variable in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
- tcpiRcvSsthresh_ - Variable in class io.grpc.channelz.v1.SocketOptionTcpInfo
- tcpiRcvWscale_ - Variable in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
- tcpiRcvWscale_ - Variable in class io.grpc.channelz.v1.SocketOptionTcpInfo
- tcpiReordering_ - Variable in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
- tcpiReordering_ - Variable in class io.grpc.channelz.v1.SocketOptionTcpInfo
- tcpiRetrans_ - Variable in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
- tcpiRetrans_ - Variable in class io.grpc.channelz.v1.SocketOptionTcpInfo
- tcpiRetransmits_ - Variable in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
- tcpiRetransmits_ - Variable in class io.grpc.channelz.v1.SocketOptionTcpInfo
- tcpiRto_ - Variable in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
- tcpiRto_ - Variable in class io.grpc.channelz.v1.SocketOptionTcpInfo
- tcpiRtt_ - Variable in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
- tcpiRtt_ - Variable in class io.grpc.channelz.v1.SocketOptionTcpInfo
- tcpiRttvar_ - Variable in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
- tcpiRttvar_ - Variable in class io.grpc.channelz.v1.SocketOptionTcpInfo
- tcpiSacked_ - Variable in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
- tcpiSacked_ - Variable in class io.grpc.channelz.v1.SocketOptionTcpInfo
- tcpiSndCwnd_ - Variable in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
- tcpiSndCwnd_ - Variable in class io.grpc.channelz.v1.SocketOptionTcpInfo
- tcpiSndMss_ - Variable in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
- tcpiSndMss_ - Variable in class io.grpc.channelz.v1.SocketOptionTcpInfo
- tcpiSndSsthresh_ - Variable in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
- tcpiSndSsthresh_ - Variable in class io.grpc.channelz.v1.SocketOptionTcpInfo
- tcpiSndWscale_ - Variable in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
- tcpiSndWscale_ - Variable in class io.grpc.channelz.v1.SocketOptionTcpInfo
- tcpiState_ - Variable in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
- tcpiState_ - Variable in class io.grpc.channelz.v1.SocketOptionTcpInfo
- tcpiUnacked_ - Variable in class io.grpc.channelz.v1.SocketOptionTcpInfo.Builder
- tcpiUnacked_ - Variable in class io.grpc.channelz.v1.SocketOptionTcpInfo
- te - Variable in class io.grpc.netty.GrpcHttp2HeadersUtils.GrpcHttp2RequestHeaders
- TE_HEADER - Static variable in class io.grpc.internal.GrpcUtil
-
Metadata.Key
for the Transfer encoding. - TE_HEADER - Static variable in class io.grpc.netty.Utils
- TE_TRAILERS - Static variable in class io.grpc.internal.GrpcUtil
-
The TE (transport encoding) header for requests over HTTP/2.
- TE_TRAILERS - Static variable in class io.grpc.netty.Utils
- tearDown() - Method in class io.grpc.internal.ClientCallImpl.CancellationHandler
- tearDownCalled - Variable in class io.grpc.internal.ClientCallImpl.CancellationHandler
- TempFileSink - Class in io.grpc.protobuf.services
-
The output file goes to the JVM's temp dir with a prefix of BINARY_INFO.
- TempFileSink() - Constructor for class io.grpc.protobuf.services.TempFileSink
- terminal - Variable in class io.grpc.protobuf.services.HealthServiceImpl
- terminated - Variable in class io.grpc.inprocess.InProcessTransport
- terminated - Variable in class io.grpc.internal.ManagedChannelImpl
- terminated - Variable in class io.grpc.internal.ServerImpl
- terminated - Variable in class io.grpc.netty.NettyServer
- terminated - Variable in class io.grpc.netty.NettyServerTransport
- terminatedLatch - Variable in class io.grpc.internal.ManagedChannelImpl
- terminatedLatch - Variable in class io.grpc.internal.OobChannel
- terminating - Variable in class io.grpc.internal.ManagedChannelImpl
- teWarningLogged - Variable in class io.grpc.netty.NettyServerHandler
- The canonical implementation pattern - Search tag in class io.grpc.LoadBalancer
- Section
- The Synchronization Context - Search tag in class io.grpc.LoadBalancer
- Section
- thisT() - Method in class io.grpc.ForwardingChannelBuilder
-
Returns the correctly typed version of the builder.
- thisT() - Method in class io.grpc.ForwardingChannelBuilder2
-
Returns the correctly typed version of the builder.
- thisT() - Method in class io.grpc.ForwardingServerBuilder
-
Returns the correctly typed version of the builder.
- thisT() - Method in class io.grpc.ManagedChannelBuilder
-
Returns the correctly typed version of the builder.
- thisT() - Method in class io.grpc.ServerBuilder
-
Returns the correctly typed version of the builder.
- thisUsesUnstableApi() - Method in class io.grpc.CallCredentials
-
Deprecated.
- ThreadlessExecutor() - Constructor for class io.grpc.stub.ClientCalls.ThreadlessExecutor
- ThreadLocalContextStorage - Class in io.grpc
-
A
ThreadLocal
-based context storage implementation. - ThreadLocalContextStorage() - Constructor for class io.grpc.ThreadLocalContextStorage
- ThreadOptimizedDeframer - Interface in io.grpc.internal
-
A
Deframer
that optimizations by taking over part of the thread safety. - THREE_DECIMAL_PLACES_SCALE_UP - Static variable in class io.grpc.internal.RetriableStream.Throttle
- threshold - Variable in class io.grpc.internal.RetriableStream.Throttle
-
Half of
maxTokens
. - threshold - Variable in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig.FailurePercentageEjection.Builder
- threshold - Variable in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig.FailurePercentageEjection
- throttle - Variable in class io.grpc.internal.ManagedChannelImpl.ChannelStreamProvider
- throttle - Variable in class io.grpc.internal.RetriableStream
- Throttle(float, float) - Constructor for class io.grpc.internal.RetriableStream.Throttle
- throttledStat - Variable in class io.grpc.rls.AdaptiveThrottler
-
Counter for the total number of requests that were throttled by either the client (this class) or the backend in recent history.
- throttler - Variable in class io.grpc.rls.CachingRlsLbClient.Builder
- throttler - Variable in class io.grpc.rls.CachingRlsLbClient
- Throttler - Interface in io.grpc.rls
-
A strategy for deciding when to throttle requests at the client.
- throwIfInterrupted() - Static method in class io.grpc.stub.ClientCalls.ThreadlessExecutor
- throwIfNotInThisSynchronizationContext() - Method in class io.grpc.SynchronizationContext
-
Throw
IllegalStateException
if this method is not called from this synchronization context. - ticker - Variable in class io.grpc.Deadline
- ticker - Variable in class io.grpc.internal.KeepAliveEnforcer
- ticker - Variable in class io.grpc.internal.ManagedChannelImpl
- ticker - Variable in class io.grpc.internal.MaxConnectionIdleManager
- ticker - Variable in class io.grpc.internal.ServerImpl
- ticker - Variable in class io.grpc.internal.ServerImplBuilder
- ticker - Variable in class io.grpc.netty.AbstractNettyHandler
- ticker - Variable in class io.grpc.netty.NettyClientTransport
- ticker - Variable in class io.grpc.netty.NettyServerHandler
- ticker - Variable in class io.grpc.rls.AdaptiveThrottler.Builder
- ticker - Variable in class io.grpc.rls.AdaptiveThrottler
- ticker - Variable in class io.grpc.rls.AdaptiveThrottler.TimeBasedAccumulator
- ticker - Variable in class io.grpc.rls.CachingRlsLbClient.Builder
- ticker - Variable in class io.grpc.rls.CachingRlsLbClient
- ticker - Variable in class io.grpc.rls.LinkedHashLruCache
- Ticker() - Constructor for class io.grpc.Deadline.Ticker
- time - Variable in class io.grpc.grpclb.GrpclbClientLoadRecorder
- time - Variable in class io.grpc.grpclb.GrpclbLoadBalancer
- time - Variable in class io.grpc.grpclb.GrpclbState
- time - Variable in class io.grpc.internal.ChannelLoggerImpl
- TimeBasedAccumulator(long, Ticker) - Constructor for class io.grpc.rls.AdaptiveThrottler.TimeBasedAccumulator
-
Interval constructor.
- TIMEOUT - Static variable in class io.grpc.internal.GrpcUtil
-
The Timeout header name.
- timeout_ - Variable in class io.grpc.binarylog.v1.ClientHeader.Builder
- timeout_ - Variable in class io.grpc.binarylog.v1.ClientHeader
- TIMEOUT_FIELD_NUMBER - Static variable in class io.grpc.binarylog.v1.ClientHeader
- TIMEOUT_KEY - Static variable in class io.grpc.internal.GrpcUtil
-
Metadata.Key
for the timeout header. - timeoutBuilder_ - Variable in class io.grpc.binarylog.v1.ClientHeader.Builder
- TimeoutMarshaller() - Constructor for class io.grpc.internal.GrpcUtil.TimeoutMarshaller
- timeoutMillis - Variable in class io.grpc.InternalChannelz.SocketOptions.Builder
- timeoutNanos - Variable in class io.grpc.internal.ManagedChannelServiceConfig.MethodInfo
- timeProvider - Variable in class io.grpc.internal.CallTracer
- timeProvider - Variable in class io.grpc.internal.ManagedChannelImpl
- timeProvider - Variable in class io.grpc.internal.OobChannel
- timeProvider - Variable in class io.grpc.internal.TransportTracer.Factory
- timeProvider - Variable in class io.grpc.internal.TransportTracer
- timeProvider - Variable in class io.grpc.protobuf.services.BinlogHelper.SinkWriterImpl
- timeProvider - Variable in class io.grpc.util.OutlierDetectionLoadBalancer
- 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.
- timeRemaining(TimeUnit) - Method in class io.grpc.Deadline
-
How much time is remaining in the specified time unit.
- timerService - Variable in class io.grpc.grpclb.GrpclbState
- timerService - Variable in class io.grpc.inprocess.InProcessChannelBuilder.InProcessClientTransportFactory
- timerService - Variable in class io.grpc.protobuf.services.HealthCheckingLoadBalancerFactory.HealthCheckState
- timeService - Variable in class io.grpc.util.OutlierDetectionLoadBalancer
- timestamp_ - Variable in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
- timestamp_ - Variable in class io.grpc.binarylog.v1.GrpcLogEntry
- timestamp_ - Variable in class io.grpc.channelz.v1.ChannelTraceEvent.Builder
- timestamp_ - Variable in class io.grpc.channelz.v1.ChannelTraceEvent
- timestamp_ - Variable in class io.grpc.lb.v1.ClientStats.Builder
- timestamp_ - Variable in class io.grpc.lb.v1.ClientStats
- TIMESTAMP_FIELD_NUMBER - Static variable in class io.grpc.binarylog.v1.GrpcLogEntry
- TIMESTAMP_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.ChannelTraceEvent
- TIMESTAMP_FIELD_NUMBER - Static variable in class io.grpc.lb.v1.ClientStats
- timestampBuilder_ - Variable in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
- timestampBuilder_ - Variable in class io.grpc.channelz.v1.ChannelTraceEvent.Builder
- timestampBuilder_ - Variable in class io.grpc.lb.v1.ClientStats.Builder
- timestampNanos - Variable in class io.grpc.InternalChannelz.ChannelTrace.Event.Builder
- timestampNanos - Variable in class io.grpc.InternalChannelz.ChannelTrace.Event
- tls - Variable in class io.grpc.InternalChannelz.Security
- tls(SslContext) - Static method in class io.grpc.netty.InternalProtocolNegotiators
-
Returns a
ProtocolNegotiator
that ensures the pipeline is set up so that TLS will be negotiated, thehandler
is added and writes to theChannel
may happen immediately, even before the TLS Handshake is complete. - tls(SslContext) - Static method in class io.grpc.netty.ProtocolNegotiators
-
Returns a
ProtocolNegotiator
that ensures the pipeline is set up so that TLS will be negotiated, thehandler
is added and writes to theChannel
may happen immediately, even before the TLS Handshake is complete. - tls(SslContext, ObjectPool<? extends Executor>, Optional<Runnable>) - Static method in class io.grpc.netty.InternalProtocolNegotiators
-
Returns a
ProtocolNegotiator
that ensures the pipeline is set up so that TLS will be negotiated, thehandler
is added and writes to theChannel
may happen immediately, even before the TLS Handshake is complete. - tls(SslContext, ObjectPool<? extends Executor>, Optional<Runnable>) - Static method in class io.grpc.netty.ProtocolNegotiators
-
Returns a
ProtocolNegotiator
that ensures the pipeline is set up so that TLS will be negotiated, thehandler
is added and writes to theChannel
may happen immediately, even before the TLS Handshake is complete. - Tls() - Constructor for class io.grpc.channelz.v1.Security.Tls
- Tls(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.channelz.v1.Security.Tls
- 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.
- TLS - Enum constant in enum io.grpc.channelz.v1.Security.ModelCase
- TLS - Enum constant in enum io.grpc.netty.NegotiationType
-
Uses TLS ALPN/NPN negotiation, assumes an SSL connection.
- TLS_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.Security
- tlsBuilder_ - Variable in class io.grpc.channelz.v1.Security.Builder
- TlsChannelCredentials - Class in io.grpc
-
TLS credentials, providing server authentication and encryption.
- TlsChannelCredentials(TlsChannelCredentials.Builder) - Constructor for class io.grpc.TlsChannelCredentials
- TlsChannelCredentials.Builder - Class in io.grpc
-
Builder for
TlsChannelCredentials
. - TlsChannelCredentials.Feature - Enum in io.grpc
-
Features to understand TLS configuration.
- tlsClientFactory(SslContext) - Static method in class io.grpc.netty.ProtocolNegotiators
- TlsProtocolNegotiatorClientFactory(SslContext) - Constructor for class io.grpc.netty.ProtocolNegotiators.TlsProtocolNegotiatorClientFactory
- TlsProtocolNegotiatorServerFactory(SslContext) - Constructor for class io.grpc.netty.ProtocolNegotiators.TlsProtocolNegotiatorServerFactory
- TlsServerCredentials - Class in io.grpc
-
TLS credentials, providing server identity and encryption.
- TlsServerCredentials(TlsServerCredentials.Builder) - Constructor for class io.grpc.TlsServerCredentials
- TlsServerCredentials.Builder - Class in io.grpc
-
Builder for
TlsServerCredentials
. - TlsServerCredentials.ClientAuth - Enum in io.grpc
-
The level of authentication the server should expect from the client.
- TlsServerCredentials.Feature - Enum in io.grpc
-
Features to understand TLS configuration.
- toAddress(SocketAddress) - Static method in class io.grpc.protobuf.services.ChannelzProtoUtil
- toAddrString(InetAddress) - Static method in class io.grpc.protobuf.services.InetAddressUtil
- toAsciiString(byte[]) - Method in class io.grpc.internal.GrpcUtil.AcceptEncodingMarshaller
- toAsciiString(Status) - Method in class io.grpc.Status.StatusCodeMarshaller
- toAsciiString(Long) - Method in class io.grpc.internal.GrpcUtil.TimeoutMarshaller
- toAsciiString(String) - Method in class io.grpc.Status.StatusMessageMarshaller
- 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
. - toAsciiString(T) - Method in interface io.grpc.Metadata.TrustedAsciiMarshaller
-
Serialize a metadata value to a ASCII string that contains only the characters listed in the class comment of
Metadata.AsciiMarshaller
. - toAsciiStringSlow(byte[], int) - Static method in class io.grpc.Status.StatusMessageMarshaller
-
Percent encode bytes to make them ASCII.
- 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.binarylog.v1.Address
- toBuilder() - Method in class io.grpc.binarylog.v1.ClientHeader
- toBuilder() - Method in class io.grpc.binarylog.v1.GrpcLogEntry
- toBuilder() - Method in class io.grpc.binarylog.v1.Message
- toBuilder() - Method in class io.grpc.binarylog.v1.Metadata
- toBuilder() - Method in class io.grpc.binarylog.v1.MetadataEntry
- toBuilder() - Method in class io.grpc.binarylog.v1.ServerHeader
- toBuilder() - Method in class io.grpc.binarylog.v1.Trailer
- toBuilder() - Method in class io.grpc.channelz.v1.Address.OtherAddress
- toBuilder() - Method in class io.grpc.channelz.v1.Address.TcpIpAddress
- toBuilder() - Method in class io.grpc.channelz.v1.Address
- toBuilder() - Method in class io.grpc.channelz.v1.Address.UdsAddress
- toBuilder() - Method in class io.grpc.channelz.v1.Channel
- toBuilder() - Method in class io.grpc.channelz.v1.ChannelConnectivityState
- toBuilder() - Method in class io.grpc.channelz.v1.ChannelData
- toBuilder() - Method in class io.grpc.channelz.v1.ChannelRef
- toBuilder() - Method in class io.grpc.channelz.v1.ChannelTrace
- toBuilder() - Method in class io.grpc.channelz.v1.ChannelTraceEvent
- toBuilder() - Method in class io.grpc.channelz.v1.GetChannelRequest
- toBuilder() - Method in class io.grpc.channelz.v1.GetChannelResponse
- toBuilder() - Method in class io.grpc.channelz.v1.GetServerRequest
- toBuilder() - Method in class io.grpc.channelz.v1.GetServerResponse
- toBuilder() - Method in class io.grpc.channelz.v1.GetServerSocketsRequest
- toBuilder() - Method in class io.grpc.channelz.v1.GetServerSocketsResponse
- toBuilder() - Method in class io.grpc.channelz.v1.GetServersRequest
- toBuilder() - Method in class io.grpc.channelz.v1.GetServersResponse
- toBuilder() - Method in class io.grpc.channelz.v1.GetSocketRequest
- toBuilder() - Method in class io.grpc.channelz.v1.GetSocketResponse
- toBuilder() - Method in class io.grpc.channelz.v1.GetSubchannelRequest
- toBuilder() - Method in class io.grpc.channelz.v1.GetSubchannelResponse
- toBuilder() - Method in class io.grpc.channelz.v1.GetTopChannelsRequest
- toBuilder() - Method in class io.grpc.channelz.v1.GetTopChannelsResponse
- toBuilder() - Method in class io.grpc.channelz.v1.Security.OtherSecurity
- toBuilder() - Method in class io.grpc.channelz.v1.Security.Tls
- toBuilder() - Method in class io.grpc.channelz.v1.Security
- toBuilder() - Method in class io.grpc.channelz.v1.Server
- toBuilder() - Method in class io.grpc.channelz.v1.ServerData
- toBuilder() - Method in class io.grpc.channelz.v1.ServerRef
- toBuilder() - Method in class io.grpc.channelz.v1.Socket
- toBuilder() - Method in class io.grpc.channelz.v1.SocketData
- toBuilder() - Method in class io.grpc.channelz.v1.SocketOption
- toBuilder() - Method in class io.grpc.channelz.v1.SocketOptionLinger
- toBuilder() - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo
- toBuilder() - Method in class io.grpc.channelz.v1.SocketOptionTimeout
- toBuilder() - Method in class io.grpc.channelz.v1.SocketRef
- toBuilder() - Method in class io.grpc.channelz.v1.Subchannel
- toBuilder() - Method in class io.grpc.channelz.v1.SubchannelRef
- toBuilder() - Method in class io.grpc.ClientStreamTracer.StreamInfo
-
Converts this StreamInfo into a new Builder.
- toBuilder() - Method in class io.grpc.health.v1.HealthCheckRequest
- toBuilder() - Method in class io.grpc.health.v1.HealthCheckResponse
- toBuilder() - Method in class io.grpc.lb.v1.ClientStats
- toBuilder() - Method in class io.grpc.lb.v1.ClientStatsPerToken
- toBuilder() - Method in class io.grpc.lb.v1.FallbackResponse
- toBuilder() - Method in class io.grpc.lb.v1.InitialLoadBalanceRequest
- toBuilder() - Method in class io.grpc.lb.v1.InitialLoadBalanceResponse
- toBuilder() - Method in class io.grpc.lb.v1.LoadBalanceRequest
- toBuilder() - Method in class io.grpc.lb.v1.LoadBalanceResponse
- toBuilder() - Method in class io.grpc.lb.v1.Server
- toBuilder() - Method in class io.grpc.lb.v1.ServerList
- toBuilder() - Method in class io.grpc.LoadBalancer.CreateSubchannelArgs
-
Returns a builder with the same initial values as this object.
- toBuilder() - Method in class io.grpc.LoadBalancer.ResolvedAddresses
-
Converts this back to a builder.
- toBuilder() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys
- toBuilder() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Name
- toBuilder() - Method in class io.grpc.lookup.v1.GrpcKeyBuilder
- toBuilder() - Method in class io.grpc.lookup.v1.HttpKeyBuilder
- toBuilder() - Method in class io.grpc.lookup.v1.NameMatcher
- toBuilder() - Method in class io.grpc.lookup.v1.RouteLookupClusterSpecifier
- toBuilder() - Method in class io.grpc.lookup.v1.RouteLookupConfig
- toBuilder() - Method in class io.grpc.lookup.v1.RouteLookupRequest
- toBuilder() - Method in class io.grpc.lookup.v1.RouteLookupResponse
- toBuilder() - Method in class io.grpc.MethodDescriptor
-
Turns this descriptor into a builder.
- toBuilder() - Method in class io.grpc.NameResolver.Args
-
Returns a builder with the same initial values as this object.
- toBuilder() - Method in class io.grpc.NameResolver.ResolutionResult
-
Converts these results back to a builder.
- toBuilder() - Method in class io.grpc.reflection.v1.ErrorResponse
- toBuilder() - Method in class io.grpc.reflection.v1.ExtensionNumberResponse
- toBuilder() - Method in class io.grpc.reflection.v1.ExtensionRequest
- toBuilder() - Method in class io.grpc.reflection.v1.FileDescriptorResponse
- toBuilder() - Method in class io.grpc.reflection.v1.ListServiceResponse
- toBuilder() - Method in class io.grpc.reflection.v1.ServerReflectionRequest
- toBuilder() - Method in class io.grpc.reflection.v1.ServerReflectionResponse
- toBuilder() - Method in class io.grpc.reflection.v1.ServiceResponse
- toBuilder() - Method in class io.grpc.reflection.v1alpha.ErrorResponse
- toBuilder() - Method in class io.grpc.reflection.v1alpha.ExtensionNumberResponse
- toBuilder() - Method in class io.grpc.reflection.v1alpha.ExtensionRequest
- toBuilder() - Method in class io.grpc.reflection.v1alpha.FileDescriptorResponse
- toBuilder() - Method in class io.grpc.reflection.v1alpha.ListServiceResponse
- toBuilder() - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest
- toBuilder() - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse
- toBuilder() - Method in class io.grpc.reflection.v1alpha.ServiceResponse
- toBuilder(CallOptions) - Static method in class io.grpc.CallOptions
-
Copy CallOptions.
- 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.protobuf.services.BinaryLogProvider.IoUtils
-
Returns the byte array.
- toByteBufferMethod(MethodDescriptor<?, ?>) - Static method in class io.grpc.protobuf.services.BinaryLogProvider
- toBytes() - Method in class io.grpc.Metadata.LazyValue
- toBytes(T) - Method in class io.grpc.Metadata.AsciiKey
- toBytes(T) - Method in class io.grpc.Metadata.BinaryKey
- toBytes(T) - Method in interface io.grpc.Metadata.BinaryMarshaller
-
Serialize a metadata value to bytes.
- toBytes(T) - Method in class io.grpc.Metadata.Key
-
Serialize a metadata value to bytes.
- toBytes(T) - Method in class io.grpc.Metadata.LazyStreamBinaryKey
- toBytes(T) - Method in class io.grpc.Metadata.TrustedAsciiKey
- toBytes(T) - Method in class io.grpc.protobuf.lite.ProtoLiteUtils.MetadataMarshaller
- toChannel(InternalInstrumented<InternalChannelz.ChannelStats>) - Static method in class io.grpc.protobuf.services.ChannelzProtoUtil
- toChannelConnectivityState(ConnectivityState) - Static method in class io.grpc.protobuf.services.ChannelzProtoUtil
- toChannelRef(InternalWithLogId) - Static method in class io.grpc.protobuf.services.ChannelzProtoUtil
- toChannelTrace(InternalChannelz.ChannelTrace) - Static method in class io.grpc.protobuf.services.ChannelzProtoUtil
- toChannelTraceEvents(List<InternalChannelz.ChannelTrace.Event>) - Static method in class io.grpc.protobuf.services.ChannelzProtoUtil
- toGetServerSocketsResponse(InternalChannelz.ServerSocketsList) - Static method in class io.grpc.protobuf.services.ChannelzProtoUtil
- toGetServersResponse(InternalChannelz.ServerList) - Static method in class io.grpc.protobuf.services.ChannelzProtoUtil
- toGetTopChannelResponse(InternalChannelz.RootChannelList) - Static method in class io.grpc.protobuf.services.ChannelzProtoUtil
- toHexString(byte[], int) - Static method in class io.grpc.servlet.jakarta.ServletServerStream
- toHexString(byte[], int) - Static method in class io.grpc.servlet.ServletServerStream
- 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.
- toJavaLogLevel(ChannelLogger.ChannelLogLevel) - Static method in class io.grpc.internal.ChannelLoggerImpl
- toJavaLogLevel(ChannelLogger.ChannelLogLevel) - Static method in class io.grpc.netty.NettyServerHandler
- token - Variable in class io.grpc.grpclb.BackendAddressGroup
- token - Variable in class io.grpc.grpclb.GrpclbState.BackendEntry
- token - Variable in class io.grpc.grpclb.GrpclbState.DropEntry
- TOKEN_ATTRIBUTE_KEY - Static variable in class io.grpc.grpclb.GrpclbConstants
-
For passing LB tokens via the EAG attributes.
- TOKEN_METADATA_KEY - Static variable in class io.grpc.grpclb.GrpclbConstants
-
The opaque token given by the remote balancer for each returned server address.
- TokenAttachingTracerFactory - Class in io.grpc.grpclb
-
Wraps a
ClientStreamTracer.Factory
, retrieves tokens from transport attributes and attaches them to headers. - TokenAttachingTracerFactory(ClientStreamTracer.Factory) - Constructor for class io.grpc.grpclb.TokenAttachingTracerFactory
- tokenCount - Variable in class io.grpc.internal.RetriableStream.Throttle
- tokenRatio - Variable in class io.grpc.internal.RetriableStream.Throttle
-
1000 times the tokenRatio field of the retryThrottling policy in service config.
- toMetadata(Status) - Static method in class io.grpc.protobuf.StatusProto
- toMetadata(Status, Metadata) - Static method in class io.grpc.protobuf.StatusProto
- toNegotiator(ChannelCredentials) - Static method in class io.grpc.netty.InternalNettyChannelCredentials
-
Converts a
ChannelCredentials
to a negotiator, in similar fashion as for a new channel. - toNegotiator(ServerCredentials) - Static method in class io.grpc.netty.InternalNettyServerCredentials
-
Converts a
ServerCredentials
to a negotiator, in similar fashion as for a new server. - TOO_MANY_REQUESTS - Static variable in class io.grpc.stub.ServerCalls
- TOO_MANY_RESPONSES - Static variable in class io.grpc.internal.ServerCallImpl
- toObject(Metadata.Key<T2>) - Method in class io.grpc.Metadata.LazyValue
- tooManyPingsRunnable - Variable in class io.grpc.netty.NettyClientTransport
- 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.
- toSecurity(InternalChannelz.Security) - Static method in class io.grpc.protobuf.services.ChannelzProtoUtil
- toServer(InternalInstrumented<InternalChannelz.ServerStats>) - Static method in class io.grpc.protobuf.services.ChannelzProtoUtil
- toServerData(InternalChannelz.ServerStats) - Static method in class io.grpc.protobuf.services.ChannelzProtoUtil
- toServerRef(InternalWithLogId) - Static method in class io.grpc.protobuf.services.ChannelzProtoUtil
- toSocket(InternalInstrumented<InternalChannelz.SocketStats>) - Static method in class io.grpc.protobuf.services.ChannelzProtoUtil
- toSocketOptionAdditional(String, String) - Static method in class io.grpc.protobuf.services.ChannelzProtoUtil
- toSocketOptionLinger(int) - Static method in class io.grpc.protobuf.services.ChannelzProtoUtil
- toSocketOptionsList(InternalChannelz.SocketOptions) - Static method in class io.grpc.protobuf.services.ChannelzProtoUtil
- toSocketOptionTcpInfo(InternalChannelz.TcpInfo) - Static method in class io.grpc.protobuf.services.ChannelzProtoUtil
- toSocketOptionTimeout(String, int) - Static method in class io.grpc.protobuf.services.ChannelzProtoUtil
- toSocketRef(InternalWithLogId) - Static method in class io.grpc.protobuf.services.ChannelzProtoUtil
- toState(ConnectivityState) - Static method in class io.grpc.protobuf.services.ChannelzProtoUtil
- toStatus() - Method in enum io.grpc.Status.Code
-
Returns a
Status
object corresponding to this status code. - toStatus(Status) - Static method in class io.grpc.protobuf.StatusProto
- toStatusException(Status) - Static method in class io.grpc.protobuf.StatusProto
-
Convert a
Status
instance to aStatusException
. - toStatusException(Status, Metadata) - Static method in class io.grpc.protobuf.StatusProto
-
Convert a
Status
instance to aStatusException
with additional metadata. - toStatusException(Status, Metadata, Throwable) - Static method in class io.grpc.protobuf.StatusProto
-
Convert a
Status
instance to aStatusException
with additional metadata and the root exception thrown. - toStatusRuntimeException(Status) - Static method in class io.grpc.protobuf.StatusProto
-
Convert a
Status
instance to aStatusRuntimeException
. - toStatusRuntimeException(Status, Metadata) - Static method in class io.grpc.protobuf.StatusProto
-
Convert a
Status
instance to aStatusRuntimeException
with additional metadata. - toStatusRuntimeException(Throwable) - Static method in class io.grpc.stub.ClientCalls
-
Wraps the given
Throwable
in aStatusRuntimeException
. - toStream() - Method in class io.grpc.Metadata.LazyValue
- toStream(T) - Method in interface io.grpc.Metadata.BinaryStreamMarshaller
-
Serializes a metadata value to an
InputStream
. - 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.ClientStreamTracer.StreamInfo
- toString() - Method in class io.grpc.ConnectivityStateInfo
- toString() - Method in enum io.grpc.Context.DirectExecutor
- toString() - Method in class io.grpc.Context.Key
- toString() - Method in class io.grpc.Deadline
- toString() - Method in class io.grpc.EquivalentAddressGroup
- toString() - Method in class io.grpc.ForwardingChannelBuilder2
- toString() - Method in class io.grpc.ForwardingServerBuilder
- toString() - Method in class io.grpc.grpclb.BackendAddressGroup
- toString() - Method in class io.grpc.grpclb.GrpclbConfig
- toString() - Method in class io.grpc.grpclb.GrpclbState.BackendEntry
- toString() - Method in class io.grpc.grpclb.GrpclbState.DropEntry
- toString() - Method in class io.grpc.grpclb.GrpclbState.ErrorEntry
- toString() - Method in class io.grpc.grpclb.GrpclbState.IdleSubchannelEntry
- toString() - Method in class io.grpc.grpclb.GrpclbState.RoundRobinPicker
- toString() - Method in class io.grpc.HttpConnectProxiedSocketAddress
- toString() - Method in class io.grpc.inprocess.InProcessServer
- toString() - Method in class io.grpc.inprocess.InProcessSocketAddress
-
Returns
InProcessSocketAddress.getName()
. - toString() - Method in class io.grpc.inprocess.InProcessTransport
- toString() - Method in class io.grpc.internal.AutoConfiguredLoadBalancerFactory.EmptyPicker
- toString() - Method in class io.grpc.internal.ClientCallImpl
- toString() - Method in class io.grpc.internal.DelayedClientCall
- toString() - Method in class io.grpc.internal.DnsNameResolver.SrvRecord
- toString() - Method in class io.grpc.internal.ForwardingClientStream
- toString() - Method in class io.grpc.internal.ForwardingClientStreamListener
- toString() - Method in class io.grpc.internal.ForwardingClientStreamTracer
- toString() - Method in class io.grpc.internal.ForwardingConnectionClientTransport
- toString() - Method in class io.grpc.internal.ForwardingManagedChannel
- toString() - Method in class io.grpc.internal.ForwardingNameResolver
- toString() - Method in class io.grpc.internal.ForwardingReadableBuffer
- toString() - Method in class io.grpc.internal.GrpcUtil.GrpcBuildVersion
- toString() - Method in class io.grpc.internal.HedgingPolicy
- toString() - Method in class io.grpc.internal.InsightBuilder
-
Get the resulting string.
- toString() - Method in class io.grpc.internal.InternalSubchannel
- toString() - Method in class io.grpc.internal.LogExceptionRunnable
- toString() - Method in class io.grpc.internal.ManagedChannelImpl.SubchannelImpl
- toString() - Method in class io.grpc.internal.ManagedChannelImpl
- toString() - Method in class io.grpc.internal.ManagedChannelServiceConfig.MethodInfo
- toString() - Method in class io.grpc.internal.ManagedChannelServiceConfig
- toString() - Method in class io.grpc.internal.OobChannel
- toString() - Method in class io.grpc.internal.PickFirstLeafLoadBalancer.Picker
- toString() - Method in class io.grpc.internal.PickFirstLoadBalancer.Picker
- toString() - Method in class io.grpc.internal.PickSubchannelArgsImpl
- toString() - Method in class io.grpc.internal.RetryPolicy
- toString() - Method in class io.grpc.internal.ServerImpl
- toString() - Method in class io.grpc.internal.ServiceConfigUtil.LbConfig
- toString() - Method in class io.grpc.internal.ServiceConfigUtil.PolicySelection
- toString() - Method in class io.grpc.InternalChannelz.ChannelTrace.Event
- toString() - Method in class io.grpc.InternalLogId
- toString() - Method in class io.grpc.LoadBalancer.CreateSubchannelArgs.Key
- toString() - Method in class io.grpc.LoadBalancer.CreateSubchannelArgs
- toString() - Method in class io.grpc.LoadBalancer.ErrorPicker
-
Deprecated.
- toString() - Method in class io.grpc.LoadBalancer.FixedResultPicker
- toString() - Method in class io.grpc.LoadBalancer.PickResult
- toString() - Method in class io.grpc.LoadBalancer.ResolvedAddresses
- toString() - Method in class io.grpc.LoadBalancerProvider
- toString() - Method in class io.grpc.LoadBalancerProvider.UnknownConfig
- 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.NameResolver.Args
- toString() - Method in class io.grpc.NameResolver.ConfigOrError
- toString() - Method in class io.grpc.NameResolver.ResolutionResult
- toString() - Method in class io.grpc.netty.CancelServerStreamCommand
- toString() - Method in class io.grpc.netty.GrpcHttp2HeadersUtils.GrpcHttp2RequestHeaders
- toString() - Method in class io.grpc.netty.GrpcHttp2HeadersUtils.GrpcHttp2ResponseHeaders
- toString() - Method in class io.grpc.netty.GrpcHttp2OutboundHeaders
- toString() - Method in class io.grpc.netty.NettyClientTransport
- toString() - Method in class io.grpc.netty.NettyServer.ListenSocket
- toString() - Method in class io.grpc.netty.NettyServer
- toString() - Method in class io.grpc.netty.NettyServerTransport
- toString() - Method in class io.grpc.netty.ProtocolNegotiationEvent
- toString() - Method in class io.grpc.netty.SendGrpcFrameCommand
- toString() - Method in class io.grpc.netty.SendResponseHeadersCommand
- toString() - Method in class io.grpc.netty.Utils.DefaultEventLoopGroupResource
- toString() - Method in class io.grpc.PartialForwardingClientCall
- toString() - Method in class io.grpc.PartialForwardingClientCallListener
- toString() - Method in class io.grpc.PartialForwardingServerCall
- toString() - Method in class io.grpc.PartialForwardingServerCallListener
- toString() - Method in class io.grpc.PartialMetricInstrument
- toString() - Method in class io.grpc.PersistentHashArrayMappedTrie.CollisionLeaf
- toString() - Method in class io.grpc.PersistentHashArrayMappedTrie.CompressedIndex
- toString() - Method in class io.grpc.PersistentHashArrayMappedTrie.Leaf
- toString() - Method in class io.grpc.protobuf.services.HealthCheckingLoadBalancerFactory.HealthCheckingLoadBalancer
- toString() - Method in class io.grpc.protobuf.services.HealthCheckingLoadBalancerFactory.HealthCheckState.HcStream
- toString() - Method in class io.grpc.protobuf.services.HealthCheckingLoadBalancerFactory.HealthCheckState
- toString() - Method in class io.grpc.protobuf.services.HealthCheckingLoadBalancerFactory.HelperImpl
- toString() - Method in class io.grpc.rls.AdaptiveThrottler.TimeBasedAccumulator
- toString() - Method in class io.grpc.rls.AdaptiveThrottler
- toString() - Method in class io.grpc.rls.AutoValue_RlsProtoData_ExtraKeys
- toString() - Method in class io.grpc.rls.AutoValue_RlsProtoData_GrpcKeyBuilder_Name
- toString() - Method in class io.grpc.rls.AutoValue_RlsProtoData_GrpcKeyBuilder
- toString() - Method in class io.grpc.rls.AutoValue_RlsProtoData_NameMatcher
- toString() - Method in class io.grpc.rls.AutoValue_RlsProtoData_RouteLookupConfig
- toString() - Method in class io.grpc.rls.AutoValue_RlsProtoData_RouteLookupRequest
- toString() - Method in class io.grpc.rls.AutoValue_RlsProtoData_RouteLookupResponse
- toString() - Method in class io.grpc.rls.CachingRlsLbClient.BackoffCacheEntry
- toString() - Method in class io.grpc.rls.CachingRlsLbClient.CachedRouteLookupResponse
- toString() - Method in class io.grpc.rls.CachingRlsLbClient.DataCacheEntry
- toString() - Method in class io.grpc.rls.CachingRlsLbClient.PendingCacheEntry
- toString() - Method in class io.grpc.rls.CachingRlsLbClient.RlsPicker
- toString() - Method in class io.grpc.rls.LbPolicyConfiguration.ChildLoadBalancingPolicy
- toString() - Method in class io.grpc.rls.LbPolicyConfiguration.ChildPolicyWrapper
- toString() - Method in class io.grpc.rls.LbPolicyConfiguration.RefCountedChildPolicyWrapper
- toString() - Method in class io.grpc.rls.LbPolicyConfiguration
- toString() - Method in class io.grpc.rls.LinkedHashLruCache.SizedValue
- toString() - Method in class io.grpc.rls.RlsRequestFactory
- toString() - Method in class io.grpc.rls.SubchannelStateManagerImpl
- toString() - Method in class io.grpc.ServiceDescriptor
- toString() - Method in class io.grpc.services.MetricReport
- toString() - Method in class io.grpc.Status
-
A string representation of the status useful for debugging.
- toString() - Method in class io.grpc.StatusOr
- toString() - Method in class io.grpc.util.ForwardingClientStreamTracer
- toString() - Method in class io.grpc.util.ForwardingLoadBalancer
- toString() - Method in class io.grpc.util.ForwardingLoadBalancerHelper
- toString() - Method in class io.grpc.util.ForwardingSubchannel
- toString() - Method in class io.grpc.util.GracefulSwitchLoadBalancer.Config
- toString() - Method in class io.grpc.util.MultiChildLoadBalancer.ChildLbState
- toString() - Method in class io.grpc.util.MultiChildLoadBalancer.Endpoint
- toString() - Method in class io.grpc.util.OutlierDetectionLoadBalancer.EndpointTracker
- toString() - Method in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionSubchannel
- toString() - Method in class io.grpc.util.RoundRobinLoadBalancer.ReadyPicker
- toSubchannel(InternalInstrumented<InternalChannelz.ChannelStats>) - Static method in class io.grpc.protobuf.services.ChannelzProtoUtil
- toSubchannelRef(InternalWithLogId) - Static method in class io.grpc.protobuf.services.ChannelzProtoUtil
- toTracerSeverity(ChannelLogger.ChannelLogLevel) - Static method in class io.grpc.internal.ChannelLoggerImpl
- touch() - Method in class io.grpc.internal.ForwardingReadableBuffer
- touch() - Method in interface io.grpc.internal.ReadableBuffer
-
Note that the current callsite has access to this buffer, or do nothing.
- touch() - Method in class io.grpc.netty.NettyReadableBuffer
- touch(Object) - Method in class io.grpc.netty.NettyServer.SharedResourceReferenceCounter
- trace(ChannelLogger.ChannelLogLevel, String) - Method in class io.grpc.internal.ChannelLoggerImpl
- trace_ - Variable in class io.grpc.channelz.v1.ChannelData.Builder
- trace_ - Variable in class io.grpc.channelz.v1.ChannelData
- trace_ - Variable in class io.grpc.channelz.v1.ServerData.Builder
- trace_ - Variable in class io.grpc.channelz.v1.ServerData
- TRACE_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.ChannelData
- TRACE_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.ServerData
- traceBuilder_ - Variable in class io.grpc.channelz.v1.ChannelData.Builder
- traceBuilder_ - Variable in class io.grpc.channelz.v1.ServerData.Builder
- traceOnly(InternalChannelz.ChannelTrace.Event) - Method in class io.grpc.internal.ChannelTracer
- tracer - Variable in class io.grpc.internal.ChannelLoggerImpl
- tracers - Variable in class io.grpc.internal.DelayedClientTransport.PendingStream
- tracers - Variable in class io.grpc.internal.FailingClientStream
- tracers - Variable in class io.grpc.internal.MetadataApplierImpl
- tracers - Variable in class io.grpc.internal.PickDetailsConsumerImpl
- tracers - Variable in class io.grpc.internal.StatsTraceContext
- tracingEnabled - Variable in class io.grpc.internal.ManagedChannelImplBuilder
- tracingEnabled - Variable in class io.grpc.internal.ServerImplBuilder
- tracker - Variable in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionPicker.ResultCountingClientStreamTracerFactory
- trackerMap - Variable in class io.grpc.util.OutlierDetectionLoadBalancer.EndpointTrackerMap
- trackersWithVolume(OutlierDetectionLoadBalancer.EndpointTrackerMap, int) - Static method in class io.grpc.util.OutlierDetectionLoadBalancer
-
Returns only the trackers that have the minimum configured volume to be considered.
- Trailer - Class in io.grpc.binarylog.v1
-
Protobuf type
grpc.binarylog.v1.Trailer
- Trailer() - Constructor for class io.grpc.binarylog.v1.Trailer
- Trailer(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.binarylog.v1.Trailer
- TRAILER - Enum constant in enum io.grpc.binarylog.v1.GrpcLogEntry.PayloadCase
- TRAILER - Enum constant in enum io.grpc.internal.GzipInflatingBuffer.State
- TRAILER_FIELD_NUMBER - Static variable in class io.grpc.binarylog.v1.GrpcLogEntry
- Trailer.Builder - Class in io.grpc.binarylog.v1
-
Protobuf type
grpc.binarylog.v1.Trailer
- trailerBuilder_ - Variable in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
- TrailerOrBuilder - Interface in io.grpc.binarylog.v1
- trailers - Variable in class io.grpc.servlet.jakarta.ServletServerStream.TrailerSupplier
- trailers - Variable in class io.grpc.servlet.ServletServerStream.TrailerSupplier
- trailers - Variable in exception class io.grpc.StatusException
- trailers - Variable in exception class io.grpc.StatusRuntimeException
- trailersCapture - Variable in class io.grpc.stub.MetadataUtils.MetadataCapturingClientInterceptor
- trailersFromThrowable(Throwable) - Static method in class io.grpc.Status
-
Extract an error trailers from the causal chain of a
Throwable
. - trailerSupplier - Variable in class io.grpc.servlet.jakarta.ServletServerStream.Sink
- trailerSupplier - Variable in class io.grpc.servlet.ServletServerStream.Sink
- TrailerSupplier() - Constructor for class io.grpc.servlet.jakarta.ServletServerStream.TrailerSupplier
- TrailerSupplier() - Constructor for class io.grpc.servlet.ServletServerStream.TrailerSupplier
- TRANSIENT_FAILURE - Enum constant in enum io.grpc.channelz.v1.ChannelConnectivityState.State
-
TRANSIENT_FAILURE = 4;
- TRANSIENT_FAILURE - Enum constant in enum io.grpc.ConnectivityState
-
There has been some transient failure (such as a TCP 3-way handshake timing out or a socket error).
- TRANSIENT_FAILURE_VALUE - Static variable in enum io.grpc.channelz.v1.ChannelConnectivityState.State
-
TRANSIENT_FAILURE = 4;
- TransmitStatusRuntimeExceptionInterceptor - Class in io.grpc.util
-
A class that intercepts uncaught exceptions of type
StatusRuntimeException
and handles them by closing theServerCall
, and transmitting the exception's status and metadata to the client. - TransmitStatusRuntimeExceptionInterceptor() - Constructor for class io.grpc.util.TransmitStatusRuntimeExceptionInterceptor
- TransmitStatusRuntimeExceptionInterceptor.SerializingServerCall<ReqT,
RespT> - Class in io.grpc.util -
A
ServerCall
that wraps around a non thread safe delegate and provides thread safe access by serializing everything on an executor. - transport - Variable in class io.grpc.internal.InternalSubchannel.TransportListener
- transport - Variable in class io.grpc.internal.KeepAliveManager.ClientKeepAlivePinger
- transport - Variable in class io.grpc.internal.MetadataApplierImpl
- transport - Variable in class io.grpc.internal.ServerImpl.ServerTransportListenerImpl
- transport - Variable in class io.grpc.InternalMethodDescriptor
- 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.
- transportClosed(ServerTransport) - Method in class io.grpc.internal.ServerImpl
-
Remove transport service from accounting collection and notify of complete shutdown if necessary.
- transportCreated(ServerTransport) - Method in class io.grpc.internal.ServerImpl.ServerListenerImpl
- 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.
- transportDataReceived(ByteBuf, boolean) - Method in class io.grpc.netty.NettyClientStream.TransportState
- transportError - Variable in class io.grpc.internal.Http2ClientStreamTransportState
- transportErrorMetadata - Variable in class io.grpc.internal.Http2ClientStreamTransportState
- transportExecutor - Variable in class io.grpc.internal.ApplicationThreadDeframerListener
- transportExecutor - Variable in class io.grpc.internal.MigratingThreadDeframer
- transportFactory - Variable in class io.grpc.internal.ClientTransportFactory.SwapChannelCredentialsResult
- transportFactory - Variable in class io.grpc.internal.InternalSubchannel
- transportFactory - Variable in class io.grpc.internal.ManagedChannelImpl
- transportFilters - Variable in class io.grpc.internal.InternalSubchannel
- transportFilters - Variable in class io.grpc.internal.ManagedChannelImpl
- transportFilters - Variable in class io.grpc.internal.ManagedChannelImplBuilder
- transportFilters - Variable in class io.grpc.internal.ServerImpl
- transportFilters - Variable in class io.grpc.internal.ServerImplBuilder
- TransportFrameUtil - Class in io.grpc.internal
-
Utility functions for transport layer framing.
- TransportFrameUtil() - Constructor for class io.grpc.internal.TransportFrameUtil
- transportHeadersReceived(Metadata) - Method in class io.grpc.internal.Http2ClientStreamTransportState
-
Called by subclasses whenever
Headers
are received from the transport. - transportHeadersReceived(Http2Headers, boolean) - Method in class io.grpc.netty.NettyClientStream.TransportState
- transportIncludeStatusCause - Variable in class io.grpc.inprocess.InProcessChannelBuilder
- transportInUse - Variable in class io.grpc.netty.ClientTransportLifecycleManager
- transportInUse(boolean) - Method in class io.grpc.internal.InternalSubchannel.TransportListener
- transportInUse(boolean) - Method in class io.grpc.internal.ManagedChannelImpl.DelayedTransportListener
- transportInUse(boolean) - Method in interface io.grpc.internal.ManagedClientTransport.Listener
-
Called whenever the transport's in-use state has changed.
- transportListener - Variable in class io.grpc.internal.MigratingThreadDeframer
- transportListener - Variable in class io.grpc.netty.NettyServerHandler
- transportListener - Variable in class io.grpc.servlet.jakarta.ServletAdapter
- transportListener - Variable in class io.grpc.servlet.ServletAdapter
- TransportListener(ConnectionClientTransport) - Constructor for class io.grpc.internal.InternalSubchannel.TransportListener
- TransportLogger() - Constructor for class io.grpc.internal.InternalSubchannel.TransportLogger
- transportProvider - Variable in class io.grpc.internal.ManagedChannelImpl
- transportProvider - Variable in class io.grpc.internal.OobChannel
- transportProvider - Variable in class io.grpc.internal.SubchannelChannel
- TransportProvider - Interface in io.grpc.internal
-
Provides transports for sending RPCs.
- transportReady - Variable in class io.grpc.netty.ClientTransportLifecycleManager
- transportReady() - Method in class io.grpc.internal.InternalSubchannel.TransportListener
- transportReady() - Method in class io.grpc.internal.ManagedChannelImpl.DelayedTransportListener
- 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 class io.grpc.ClientTransportFilter
-
Called when a transport is ready to accept traffic (when a connection has been established).
- transportReady(Attributes) - Method in class io.grpc.internal.ServerImpl.ServerTransportListenerImpl
- 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) - Method in class io.grpc.internal.AbstractServerStream.TransportState
-
Notifies failure to the listener of the stream.
- 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.
- transports - Variable in class io.grpc.internal.InternalSubchannel
-
All transports that are not terminated.
- transports - Variable in class io.grpc.internal.ServerImpl
-
transportServer
and services encapsulating something similar to a TCP connection. - transportServer - Variable in class io.grpc.internal.ServerImpl
-
Service encapsulating something similar to an accept() socket.
- transportServersTerminated - Variable in class io.grpc.internal.ServerImpl
- transportShutdown - Variable in class io.grpc.netty.ClientTransportLifecycleManager
- transportShutdown(Status) - Method in class io.grpc.internal.InternalSubchannel.TransportListener
- transportShutdown(Status) - Method in class io.grpc.internal.ManagedChannelImpl.DelayedTransportListener
- transportShutdown(Status) - Method in interface io.grpc.internal.ManagedClientTransport.Listener
-
The transport is shutting down.
- transportSocketType - Variable in class io.grpc.netty.NettyChannelBuilder.NettyTransportFactory
- transportSocketType - Variable in class io.grpc.netty.NettyChannelBuilder
- transportState - Variable in class io.grpc.servlet.jakarta.ServletServerStream
- transportState - Variable in class io.grpc.servlet.ServletServerStream
- transportState() - Method in class io.grpc.internal.AbstractClientStream
-
Obtain the transport state corresponding to this stream.
- transportState() - Method in class io.grpc.internal.AbstractServerStream
- transportState() - Method in class io.grpc.internal.AbstractStream
-
Obtain the transport state corresponding to this stream.
- transportState() - Method in class io.grpc.netty.NettyClientStream
- transportState() - Method in class io.grpc.netty.NettyServerStream
- transportState() - Method in class io.grpc.servlet.jakarta.ServletServerStream
- transportState() - Method in class io.grpc.servlet.ServletServerStream
- TransportState(int, StatsTraceContext, TransportTracer) - Constructor for class io.grpc.internal.AbstractServerStream.TransportState
- TransportState(int, StatsTraceContext, TransportTracer) - Constructor for class io.grpc.internal.AbstractStream.TransportState
- TransportState(int, StatsTraceContext, TransportTracer, CallOptions) - Constructor for class io.grpc.internal.AbstractClientStream.TransportState
- TransportState(NettyClientHandler, EventLoop, int, StatsTraceContext, TransportTracer, String, CallOptions) - Constructor for class io.grpc.netty.NettyClientStream.TransportState
- TransportState(NettyServerHandler, EventLoop, Http2Stream, int, StatsTraceContext, TransportTracer, String) - Constructor for class io.grpc.netty.NettyServerStream.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 - Variable in class io.grpc.netty.ClientTransportLifecycleManager
- transportTerminated() - Method in class io.grpc.internal.InternalSubchannel.TransportListener
- transportTerminated() - Method in class io.grpc.internal.ManagedChannelImpl.DelayedTransportListener
- transportTerminated() - Method in interface io.grpc.internal.ManagedClientTransport.Listener
-
The transport completed shutting down.
- transportTerminated() - Method in class io.grpc.internal.ServerImpl.ServerTransportListenerImpl
- transportTerminated() - Method in interface io.grpc.internal.ServerTransportListener
-
The transport completed shutting down.
- transportTerminated(Attributes) - Method in class io.grpc.ClientTransportFilter
-
Called when a transport completed shutting down.
- transportTerminated(Attributes) - Method in class io.grpc.ServerTransportFilter
-
Called when a transport is terminated.
- transportThreadExecutor - Variable in class io.grpc.servlet.jakarta.ServletServerStream.ServletTransportState
- transportThreadExecutor - Variable in class io.grpc.servlet.ServletServerStream.ServletTransportState
- transportTracer - Variable in class io.grpc.internal.AbstractClientStream
- transportTracer - Variable in class io.grpc.internal.AbstractStream.TransportState
- transportTracer - Variable in class io.grpc.internal.MessageDeframer
- transportTracer - Variable in class io.grpc.netty.NettyClientHandler
- transportTracer - Variable in class io.grpc.netty.NettyClientTransport
-
Since not thread-safe, may only be used from event loop.
- transportTracer - Variable in class io.grpc.netty.NettyServerHandler
- transportTracer - Variable in class io.grpc.netty.NettyServerTransport
- TransportTracer - Class in io.grpc.internal
-
A class for gathering statistics about a transport.
- TransportTracer() - Constructor for class io.grpc.internal.TransportTracer
- TransportTracer(TimeProvider) - 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.netty.NettyChannelBuilder.NettyTransportFactory
- transportTracerFactory - Variable in class io.grpc.netty.NettyChannelBuilder
- transportTracerFactory - Variable in class io.grpc.netty.NettyServer
- transportTracerFactory - Variable in class io.grpc.netty.NettyServerBuilder
- transportTrailersReceived(Metadata) - Method in class io.grpc.internal.Http2ClientStreamTransportState
-
Called by subclasses for the terminal trailer metadata on a stream.
- triggerPendingRpcProcessing() - Method in class io.grpc.rls.CachingRlsLbClient.RlsLbHelper
- truncated - Variable in class io.grpc.protobuf.services.BinlogHelper.MaybeTruncated
- trustDomain - Variable in class io.grpc.internal.SpiffeUtil.SpiffeId
- TrustedAsciiKey(String, boolean, Metadata.TrustedAsciiMarshaller<T>) - Constructor for class io.grpc.Metadata.TrustedAsciiKey
-
Keys have a name and an ASCII marshaller used for serialization.
- trustManager(File) - Method in class io.grpc.TlsChannelCredentials.Builder
-
Use the provided root certificates to verify the server's identity instead of the system's default.
- trustManager(File) - Method in class io.grpc.TlsServerCredentials.Builder
-
Use the provided root certificates to verify the client's identity instead of the system's default.
- trustManager(InputStream) - Method in class io.grpc.TlsChannelCredentials.Builder
-
Use the provided root certificates to verify the server's identity instead of the system's default.
- trustManager(InputStream) - Method in class io.grpc.TlsServerCredentials.Builder
-
Use the provided root certificates to verify the client's identity instead of the system's default.
- trustManager(TrustManager...) - Method in class io.grpc.TlsChannelCredentials.Builder
-
Have the provided trust manager verify the server's identity instead of the system's default.
- trustManager(TrustManager...) - Method in class io.grpc.TlsServerCredentials.Builder
-
Have the provided trust manager verify the client's identity instead of the system's default.
- trustManagers - Variable in class io.grpc.netty.FixedTrustManagerFactory.FixedTrustManagerFactorySpi
- trustManagers - Variable in class io.grpc.TlsChannelCredentials.Builder
- trustManagers - Variable in class io.grpc.TlsChannelCredentials
- trustManagers - Variable in class io.grpc.TlsServerCredentials.Builder
- trustManagers - Variable in class io.grpc.TlsServerCredentials
- tryAcceptResolvedAddresses(LoadBalancer.ResolvedAddresses) - Method in class io.grpc.internal.AutoConfiguredLoadBalancerFactory.AutoConfiguredLoadBalancer
-
Returns non-OK status if the delegate rejects the resolvedAddresses (e.g.
- type - Variable in class io.grpc.MethodDescriptor.Builder
- type - Variable in class io.grpc.MethodDescriptor
- Type(int) - Constructor for enum io.grpc.binarylog.v1.Address.Type
- type_ - Variable in class io.grpc.binarylog.v1.Address.Builder
- type_ - Variable in class io.grpc.binarylog.v1.Address
- type_ - Variable in class io.grpc.binarylog.v1.GrpcLogEntry.Builder
- type_ - Variable in class io.grpc.binarylog.v1.GrpcLogEntry
- TYPE_FIELD_NUMBER - Static variable in class io.grpc.binarylog.v1.Address
- TYPE_FIELD_NUMBER - Static variable in class io.grpc.binarylog.v1.GrpcLogEntry
- TYPE_IPV4 - Enum constant in enum io.grpc.binarylog.v1.Address.Type
-
address is in 1.2.3.4 form
- TYPE_IPV4_VALUE - Static variable in enum io.grpc.binarylog.v1.Address.Type
-
address is in 1.2.3.4 form
- TYPE_IPV6 - Enum constant in enum io.grpc.binarylog.v1.Address.Type
-
address is in IPv6 canonical form (RFC5952 section 4) The scope is NOT included in the address string.
- TYPE_IPV6_VALUE - Static variable in enum io.grpc.binarylog.v1.Address.Type
-
address is in IPv6 canonical form (RFC5952 section 4) The scope is NOT included in the address string.
- TYPE_UNIX - Enum constant in enum io.grpc.binarylog.v1.Address.Type
-
address is UDS string
- TYPE_UNIX_VALUE - Static variable in enum io.grpc.binarylog.v1.Address.Type
-
address is UDS string
- TYPE_UNKNOWN - Enum constant in enum io.grpc.binarylog.v1.Address.Type
-
TYPE_UNKNOWN = 0;
- TYPE_UNKNOWN_VALUE - Static variable in enum io.grpc.binarylog.v1.Address.Type
-
TYPE_UNKNOWN = 0;
- typeName - Variable in class io.grpc.InternalLogId
U
- UBYTE_OP - Static variable in class io.grpc.internal.CompositeReadableBuffer
- UDS_ADDRESS - Enum constant in enum io.grpc.channelz.v1.Address.AddressCase
- UDS_ADDRESS_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.Address
- UdsAddress() - Constructor for class io.grpc.channelz.v1.Address.UdsAddress
- UdsAddress(GeneratedMessage.Builder<?>) - Constructor for class io.grpc.channelz.v1.Address.UdsAddress
- udsAddressBuilder_ - Variable in class io.grpc.channelz.v1.Address.Builder
- UdsNameResolver - Class in io.grpc.netty
- UdsNameResolver(String, String, NameResolver.Args) - Constructor for class io.grpc.netty.UdsNameResolver
- UdsNameResolverProvider - Class in io.grpc.netty
- UdsNameResolverProvider() - Constructor for class io.grpc.netty.UdsNameResolverProvider
- UdsNettyChannelProvider - Class in io.grpc.netty
-
Provider for
NettyChannelBuilder
instances for UDS channels. - UdsNettyChannelProvider() - Constructor for class io.grpc.netty.UdsNettyChannelProvider
- unacked - Variable in class io.grpc.InternalChannelz.TcpInfo.Builder
- unacked - Variable in class io.grpc.InternalChannelz.TcpInfo
- UNARY - Enum constant in enum io.grpc.MethodDescriptor.MethodType
-
One request message followed by one response message.
- unaryRequest - Variable in class io.grpc.internal.ClientCallImpl
- UnaryServerCallHandler(ServerCalls.UnaryRequestMethod<ReqT, RespT>, boolean) - Constructor for class io.grpc.stub.ServerCalls.UnaryServerCallHandler
- UnaryServerCallListener(ServerCalls.ServerCallStreamObserverImpl<ReqT, RespT>, ServerCall<ReqT, RespT>) - Constructor for class io.grpc.stub.ServerCalls.UnaryServerCallHandler.UnaryServerCallListener
- UnaryStreamToFuture(ClientCalls.GrpcFuture<RespT>) - Constructor for class io.grpc.stub.ClientCalls.UnaryStreamToFuture
- UNAUTHENTICATED - Enum constant in enum io.grpc.Status.Code
-
The request does not have valid authentication credentials for the operation.
- UNAUTHENTICATED - Static variable in class io.grpc.Status
-
The request does not have valid authentication credentials for the operation.
- UNAVAILABILITY_CAUSE - Static variable in class io.grpc.netty.GrpcSslContexts.ConscryptHolder
- unavailabilityCause() - Method in interface io.grpc.internal.DnsNameResolver.ResourceResolverFactory
-
Returns the reason why the resource resolver cannot be created.
- unavailabilityCause() - Method in class io.grpc.internal.JndiResourceResolverFactory
- UNAVAILABLE - Enum constant in enum io.grpc.Status.Code
-
The service is currently unavailable.
- UNAVAILABLE - Static variable in class io.grpc.Status
-
The service is currently unavailable.
- unavailableException(String) - Static method in class io.grpc.netty.ProtocolNegotiators
- uncancellableSurrogate - Variable in class io.grpc.Context.CancellableContext
- uncaughtExceptionHandler - Variable in class io.grpc.inprocess.InProcessTransport
- uncaughtExceptionHandler - Variable in class io.grpc.SynchronizationContext
- uncommittedRetriableStreams - Variable in class io.grpc.internal.ManagedChannelImpl.UncommittedRetriableStreamsRegistry
- uncommittedRetriableStreamsRegistry - Variable in class io.grpc.internal.ManagedChannelImpl
- UncommittedRetriableStreamsRegistry() - Constructor for class io.grpc.internal.ManagedChannelImpl.UncommittedRetriableStreamsRegistry
- UNCOMPRESSED - Static variable in class io.grpc.internal.MessageFramer
- uncompressedIndex(int, int) - Static method in class io.grpc.PersistentHashArrayMappedTrie.CompressedIndex
- understoodServerTlsFeatures - Static variable in class io.grpc.netty.ProtocolNegotiators
- understoodTlsFeatures - Static variable in class io.grpc.netty.ProtocolNegotiators
- uneject() - Method in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionSubchannel
- unejectSubchannels() - Method in class io.grpc.util.OutlierDetectionLoadBalancer.EndpointTracker
-
Uneject a currently ejected address.
- UnhelpfulSecurityProvider - Class in io.grpc.netty
-
A stand-in provider when you must provide a provider but you don't actually have one.
- UnhelpfulSecurityProvider() - Constructor for class io.grpc.netty.UnhelpfulSecurityProvider
- uniformRandom(double, double) - Method in class io.grpc.internal.ExponentialBackoffPolicy
- UNIMPLEMENTED - Enum constant in enum io.grpc.Status.Code
-
Operation is not implemented or not supported/enabled in this service.
- UNIMPLEMENTED - Static variable in class io.grpc.Status
-
Operation is not implemented or not supported/enabled in this service.
- unit - Variable in class io.grpc.PartialMetricInstrument
- UNKNOWN - Enum constant in enum io.grpc.channelz.v1.ChannelConnectivityState.State
-
UNKNOWN = 0;
- UNKNOWN - Enum constant in enum io.grpc.health.v1.HealthCheckResponse.ServingStatus
-
UNKNOWN = 0;
- UNKNOWN - Enum constant in enum io.grpc.MethodDescriptor.MethodType
-
Cardinality and temporal relationships are not known.
- UNKNOWN - Enum constant in enum io.grpc.Status.Code
-
Unknown error.
- UNKNOWN - Static variable in class io.grpc.Status
-
Unknown error.
- UNKNOWN_CONFIG - Static variable in class io.grpc.LoadBalancerProvider
-
A sentinel value indicating that service config is not supported.
- UNKNOWN_SCHEME - Static variable in class io.grpc.NameResolverRegistry
- UNKNOWN_VALUE - Static variable in enum io.grpc.channelz.v1.ChannelConnectivityState.State
-
UNKNOWN = 0;
- UNKNOWN_VALUE - Static variable in enum io.grpc.health.v1.HealthCheckResponse.ServingStatus
-
UNKNOWN = 0;
- UnknownConfig() - Constructor for class io.grpc.LoadBalancerProvider.UnknownConfig
- unprocessed - Variable in class io.grpc.internal.MessageDeframer
- unquote(String) - Static method in class io.grpc.internal.JndiResourceResolverFactory.JndiResourceResolver
-
Undo the quoting done in
invalid reference
com.sun.jndi.dns.ResourceRecord#decodeTxt
- UNRECOGNIZED - Enum constant in enum io.grpc.binarylog.v1.Address.Type
- UNRECOGNIZED - Enum constant in enum io.grpc.binarylog.v1.GrpcLogEntry.EventType
- UNRECOGNIZED - Enum constant in enum io.grpc.binarylog.v1.GrpcLogEntry.Logger
- UNRECOGNIZED - Enum constant in enum io.grpc.channelz.v1.ChannelConnectivityState.State
- UNRECOGNIZED - Enum constant in enum io.grpc.channelz.v1.ChannelTraceEvent.Severity
- UNRECOGNIZED - Enum constant in enum io.grpc.health.v1.HealthCheckResponse.ServingStatus
- UNRECOGNIZED - Enum constant in enum io.grpc.lookup.v1.RouteLookupRequest.Reason
- unregisterInstance() - Method in class io.grpc.inprocess.InProcessServer
- UNRESERVED_CHARACTERS - Static variable in class io.grpc.internal.GrpcUtil.AuthorityEscaper
- UNSIGNED_SHORT_SIZE - Static variable in class io.grpc.internal.GzipInflatingBuffer
- UnsupportedClientTransportFactoryBuilder() - Constructor for class io.grpc.internal.ManagedChannelImplBuilder.UnsupportedClientTransportFactoryBuilder
- unwrapLoadBalancingConfig(Map<String, ?>) - Static method in class io.grpc.internal.ServiceConfigUtil
-
Unwrap a LoadBalancingConfig JSON object into a
ServiceConfigUtil.LbConfig
. - unwrapLoadBalancingConfigList(List<Map<String, ?>>) - Static method in class io.grpc.internal.ServiceConfigUtil
-
Given a JSON list of LoadBalancingConfigs, and convert it into a list of LbConfig.
- update(NameResolver.ConfigOrError) - Method in class io.grpc.internal.ServiceConfigState
- updateAddresses(List<EquivalentAddressGroup>) - Method in class io.grpc.internal.InternalSubchannel
-
Replaces the existing addresses, avoiding unnecessary reconnects.
- updateAddresses(List<EquivalentAddressGroup>) - Method in class io.grpc.internal.ManagedChannelImpl.SubchannelImpl
- updateAddresses(List<EquivalentAddressGroup>) - Method in class io.grpc.internal.OobChannel
- updateAddresses(List<EquivalentAddressGroup>) - Method in class io.grpc.LoadBalancer.Subchannel
-
Replaces the existing addresses used with this
Subchannel
. - updateAddresses(List<EquivalentAddressGroup>) - Method in class io.grpc.util.ForwardingSubchannel
- updateAddresses(List<EquivalentAddressGroup>) - Method in class io.grpc.util.OutlierDetectionLoadBalancer.OutlierDetectionSubchannel
- updateBalancingState(ConnectivityState, LoadBalancer.SubchannelPicker) - Method in class io.grpc.internal.ManagedChannelImpl.LbHelperImpl
- updateBalancingState(ConnectivityState, LoadBalancer.SubchannelPicker) - Method in class io.grpc.internal.PickFirstLeafLoadBalancer
- updateBalancingState(ConnectivityState, LoadBalancer.SubchannelPicker) - Method in class io.grpc.internal.PickFirstLoadBalancer
- updateBalancingState(ConnectivityState, LoadBalancer.SubchannelPicker) - Method in class io.grpc.LoadBalancer.Helper
-
Set a new state with a new picker to the channel.
- updateBalancingState(ConnectivityState, LoadBalancer.SubchannelPicker) - Method in class io.grpc.rls.CachingRlsLbClient.RlsLbHelper
- updateBalancingState(ConnectivityState, LoadBalancer.SubchannelPicker) - Method in class io.grpc.rls.ChildLoadBalancerHelper
-
Updates balancing state from one or more subchannels tracked in the
SubchannelStateManager
. - updateBalancingState(ConnectivityState, LoadBalancer.SubchannelPicker) - Method in class io.grpc.rls.LbPolicyConfiguration.ChildPolicyWrapper.ChildPolicyReportingHelper
- updateBalancingState(ConnectivityState, LoadBalancer.SubchannelPicker) - Method in class io.grpc.util.ForwardingLoadBalancerHelper
- updateBalancingState(ConnectivityState, LoadBalancer.SubchannelPicker) - Method in class io.grpc.util.MultiChildLoadBalancer.ChildLbState.ChildLbStateHelper
-
Update current state and picker for this child and then use
MultiChildLoadBalancer.updateOverallBalancingState()
for the parent LB. - updateBalancingState(ConnectivityState, LoadBalancer.SubchannelPicker) - Method in class io.grpc.util.OutlierDetectionLoadBalancer.ChildHelper
- updateBalancingState(ConnectivityState, LoadBalancer.SubchannelPicker) - Method in class io.grpc.util.RoundRobinLoadBalancer
- updateBuilder(InternalChannelz.ChannelStats.Builder) - Method in class io.grpc.internal.CallTracer
- updateBuilder(InternalChannelz.ChannelStats.Builder) - Method in class io.grpc.internal.ChannelTracer
- updateBuilder(InternalChannelz.ServerStats.Builder) - Method in class io.grpc.internal.CallTracer
- updateCachedSubchannelState(LoadBalancer.Subchannel, ConnectivityStateInfo) - Method in class io.grpc.grpclb.CachedSubchannelPool
- updateChildrenWithResolvedAddresses(Map<Object, LoadBalancer.ResolvedAddresses>) - Method in class io.grpc.util.MultiChildLoadBalancer
-
Returns removed children.
- updateConfigSelector(InternalConfigSelector) - Method in class io.grpc.internal.ManagedChannelImpl.RealChannel
- updated - Variable in class io.grpc.internal.ServiceConfigState
- updateEntrySize(K) - Method in class io.grpc.rls.LinkedHashLruCache
-
Updates size for given key if entry exists.
- updateGroups(List<EquivalentAddressGroup>) - Method in class io.grpc.internal.InternalSubchannel.Index
-
Update to new groups, resetting the current index.
- updateGroups(List<EquivalentAddressGroup>) - Method in class io.grpc.internal.PickFirstLeafLoadBalancer.Index
-
Update to new groups, resetting the current index.
- updateHeaders(Metadata, int) - Method in class io.grpc.internal.RetriableStream
-
Adds grpc-previous-rpc-attempts in the headers of a retry/hedging RPC.
- updateHealthCheckedState(PickFirstLeafLoadBalancer.SubchannelData) - Method in class io.grpc.internal.PickFirstLeafLoadBalancer
- updateIdentityCredentials(File, File) - Method in class io.grpc.util.AdvancedTlsX509KeyManager
-
Updates certificate chains and the private key from the local file paths.
- updateIdentityCredentials(File, File, long, TimeUnit, ScheduledExecutorService) - Method in class io.grpc.util.AdvancedTlsX509KeyManager
-
Schedules a
ScheduledExecutorService
to read certificate chains and private key from the local file paths periodically, and update the cached identity credentials if they are both updated. - updateIdentityCredentials(X509Certificate[], PrivateKey) - Method in class io.grpc.util.AdvancedTlsX509KeyManager
-
Updates the current cached private key and cert chains.
- updateIdentityCredentials(PrivateKey, X509Certificate[]) - Method in class io.grpc.util.AdvancedTlsX509KeyManager
- updateIdentityCredentialsFromFile(File, File) - Method in class io.grpc.util.AdvancedTlsX509KeyManager
-
Deprecated.
- updateIdentityCredentialsFromFile(File, File, long, TimeUnit, ScheduledExecutorService) - Method in class io.grpc.util.AdvancedTlsX509KeyManager
- updateMeasures(List<MetricInstrument>) - Method in interface io.grpc.MetricSink
- updateObjectInUse(T, boolean) - Method in class io.grpc.internal.InUseStateAggregator
-
Update the in-use state of an object.
- updateOobChannelAddresses(ManagedChannel, EquivalentAddressGroup) - Method in class io.grpc.internal.ManagedChannelImpl.LbHelperImpl
- updateOobChannelAddresses(ManagedChannel, EquivalentAddressGroup) - Method in class io.grpc.LoadBalancer.Helper
-
Updates the addresses used for connections in the
Channel
that was created byLoadBalancer.Helper.createOobChannel(EquivalentAddressGroup, String)
. - updateOobChannelAddresses(ManagedChannel, EquivalentAddressGroup) - Method in class io.grpc.util.ForwardingLoadBalancerHelper
- updateOobChannelAddresses(ManagedChannel, List<EquivalentAddressGroup>) - Method in class io.grpc.internal.ManagedChannelImpl.LbHelperImpl
- updateOobChannelAddresses(ManagedChannel, List<EquivalentAddressGroup>) - Method in class io.grpc.LoadBalancer.Helper
-
Updates the addresses with a new EAG list.
- updateOobChannelAddresses(ManagedChannel, List<EquivalentAddressGroup>) - Method in class io.grpc.util.ForwardingLoadBalancerHelper
- updateOverallBalancingState() - Method in class io.grpc.util.MultiChildLoadBalancer
-
Using the state of all children will calculate the current connectivity state, update fields, generate a picker and then call
LoadBalancer.Helper.updateBalancingState(ConnectivityState, SubchannelPicker)
. - updateOverallBalancingState() - Method in class io.grpc.util.RoundRobinLoadBalancer
-
Updates picker with the list of active subchannels (state == READY).
- UpdateResult(boolean, long, long) - Constructor for class io.grpc.util.AdvancedTlsX509KeyManager.UpdateResult
- updateServerList(List<GrpclbState.DropEntry>, List<BackendAddressGroup>, GrpclbClientLoadRecorder) - Method in class io.grpc.grpclb.GrpclbState
-
Populate backend servers to be used based on the given list of addresses.
- updateState(ConnectivityState) - Method in class io.grpc.internal.PickFirstLeafLoadBalancer.SubchannelData
- updateState(String, ConnectivityState) - Method in interface io.grpc.rls.SubchannelStateManager
-
Registers and updates state for given subchannel.
- updateState(String, ConnectivityState) - Method in class io.grpc.rls.SubchannelStateManagerImpl
- updateSubchannelPicker(LoadBalancer.SubchannelPicker) - Method in class io.grpc.internal.ManagedChannelImpl
- updateTrackerConfigs(OutlierDetectionLoadBalancer.OutlierDetectionLoadBalancerConfig) - Method in class io.grpc.util.OutlierDetectionLoadBalancer.EndpointTrackerMap
- updateTrustCredentials(File) - Method in class io.grpc.util.AdvancedTlsX509TrustManager
-
Updates the trust certificates from a local file path.
- updateTrustCredentials(File, long, TimeUnit, ScheduledExecutorService) - Method in class io.grpc.util.AdvancedTlsX509TrustManager
-
Schedules a
ScheduledExecutorService
to read trust certificates from a local file path periodically, and updates the cached trust certs if there is an update. - updateTrustCredentials(X509Certificate[]) - Method in class io.grpc.util.AdvancedTlsX509TrustManager
-
Updates the current cached trust certificates as well as the key store.
- updateTrustCredentialsFromFile(File) - Method in class io.grpc.util.AdvancedTlsX509TrustManager
-
Deprecated.
- updateTrustCredentialsFromFile(File, long, TimeUnit, ScheduledExecutorService) - Method in class io.grpc.util.AdvancedTlsX509TrustManager
- updateWindow() - Method in class io.grpc.netty.AbstractNettyHandler.FlowControlPinger
- UPPER_HEX_DIGITS - Static variable in class io.grpc.internal.GrpcUtil.AuthorityEscaper
- URI_PATTERN - Static variable in class io.grpc.internal.ManagedChannelImplBuilder
- URI_SAN_TYPE - Static variable in class io.grpc.internal.SpiffeUtil
- US_ASCII - Static variable in class io.grpc.internal.GrpcUtil
- US_ASCII - Static variable in class io.grpc.InternalMetadata
-
Copy of StandardCharsets, which is only available on Java 1.7 and above.
- Usage example - Search tag in class io.grpc.inprocess.InProcessServerBuilder
- Section
- Usage examples - Search tag in class io.grpc.ClientCall
- Section
- Usage in tests - Search tag in class io.grpc.inprocess.InProcessServerBuilder
- Section
- USE_PARAMETER_VALUE - Static variable in class io.grpc.internal.SpiffeUtil
- useFallback(LoadBalancer.PickSubchannelArgs) - Method in class io.grpc.rls.CachingRlsLbClient.RlsPicker
-
Uses Subchannel connected to default target.
- useFallbackBackends() - Method in class io.grpc.grpclb.GrpclbState
-
Populate backend servers to be used from the fallback backends.
- useGet - Variable in class io.grpc.internal.AbstractClientStream
- useGetForSafeMethods - Variable in class io.grpc.netty.NettyChannelBuilder.NettyTransportFactory
- useGetForSafeMethods - Variable in class io.grpc.netty.NettyChannelBuilder
-
If true, indicates that the transport may use the GET method for RPCs, and may include the request body in the query params.
- useGetForSafeMethods - Variable in class io.grpc.netty.NettyClientTransport
- useInputStreamMessages(ServerServiceDefinition) - Static method in class io.grpc.ServerInterceptors
-
Create a new
ServerServiceDefinition
whoseMethodDescriptor
serializes to and from InputStream for all methods. - useMarshalledMessages(ServerServiceDefinition, MethodDescriptor.Marshaller<ReqT>, MethodDescriptor.Marshaller<RespT>) - Static method in class io.grpc.ServerInterceptors
-
Create a new
ServerServiceDefinition
withMethodDescriptor
for deserializing requests and separateMethodDescriptor
for serializing responses. - useMarshalledMessages(ServerServiceDefinition, MethodDescriptor.Marshaller<T>) - Static method in class io.grpc.ServerInterceptors
-
Create a new
ServerServiceDefinition
whoseMethodDescriptor
serializes to and from T for all methods. - useNioTransport(NettyChannelBuilder) - Static method in class io.grpc.netty.InternalNettyChannelBuilder
-
Sets
Channel
andEventLoopGroup
to Nio. - useNioTransport(NettyServerBuilder) - Static method in class io.grpc.netty.InternalNettyServerBuilder
-
Sets
Channel
andEventLoopGroup
s to Nio. - usePlaintext() - Method in class io.grpc.ForwardingChannelBuilder
- usePlaintext() - Method in class io.grpc.ForwardingChannelBuilder2
- usePlaintext() - Method in class io.grpc.inprocess.InProcessChannelBuilder
-
Does nothing.
- usePlaintext() - Method in class io.grpc.ManagedChannelBuilder
-
Use of a plaintext connection to the server.
- usePlaintext() - Method in class io.grpc.netty.NettyChannelBuilder
-
Equivalent to using
NettyChannelBuilder.negotiationType(NegotiationType)
withPLAINTEXT
. - USER_AGENT - Static variable in class io.grpc.netty.Utils
- USER_AGENT_KEY - Static variable in class io.grpc.internal.GrpcUtil
-
Metadata.Key
for the Content-Type request/response header. - USER_PING_PAYLOAD - Static variable in class io.grpc.netty.NettyClientHandler
- userAgent - Variable in class io.grpc.inprocess.InProcessTransport
- userAgent - Variable in class io.grpc.internal.ClientTransportFactory.ClientTransportOptions
- userAgent - Variable in class io.grpc.internal.GrpcUtil.GrpcBuildVersion
- userAgent - Variable in class io.grpc.internal.InternalSubchannel
- userAgent - Variable in class io.grpc.internal.ManagedChannelImpl
- userAgent - Variable in class io.grpc.internal.ManagedChannelImplBuilder
- userAgent - Variable in class io.grpc.netty.NettyClientStream
- userAgent - Variable in class io.grpc.netty.NettyClientTransport
- userAgent(String) - Method in class io.grpc.ForwardingChannelBuilder
- userAgent(String) - Method in class io.grpc.ForwardingChannelBuilder2
- userAgent(String) - Method in class io.grpc.internal.ManagedChannelImplBuilder
- userAgent(String) - Method in class io.grpc.ManagedChannelBuilder
-
Provides a custom
User-Agent
for the application. - userEventTriggered(ChannelHandlerContext, Object) - Method in class io.grpc.netty.ProtocolNegotiators.GrpcNegotiationHandler
- userEventTriggered(ChannelHandlerContext, Object) - Method in class io.grpc.netty.ProtocolNegotiators.Http2UpgradeAndGrpcHandler
- userEventTriggered(ChannelHandlerContext, Object) - Method in class io.grpc.netty.ProtocolNegotiators.ProtocolNegotiationHandler
- userEventTriggered(ChannelHandlerContext, Object) - Method in class io.grpc.netty.ProtocolNegotiators.ServerTlsHandler
- userEventTriggered0(ChannelHandlerContext, Object) - Method in class io.grpc.netty.ProtocolNegotiators.ClientTlsHandler
- userEventTriggered0(ChannelHandlerContext, Object) - Method in class io.grpc.netty.ProtocolNegotiators.ProtocolNegotiationHandler
- userEventTriggered0(ChannelHandlerContext, Object) - Method in class io.grpc.netty.ProtocolNegotiators.ProxyProtocolNegotiationHandler
- username - Variable in class io.grpc.HttpConnectProxiedSocketAddress.Builder
- username - Variable in class io.grpc.HttpConnectProxiedSocketAddress
- userName - Variable in class io.grpc.netty.ProtocolNegotiators.ProxyProtocolNegotiationHandler
- useSharedTimer - Variable in class io.grpc.inprocess.InProcessChannelBuilder.InProcessClientTransportFactory
- useSystemDefaultTrustCerts() - Method in class io.grpc.util.AdvancedTlsX509TrustManager
-
Uses the default trust certificates stored on user's local system.
- useTransportSecurity() - Method in class io.grpc.ForwardingChannelBuilder
- useTransportSecurity() - Method in class io.grpc.ForwardingChannelBuilder2
- useTransportSecurity() - Method in class io.grpc.inprocess.InProcessChannelBuilder
-
Does nothing.
- useTransportSecurity() - Method in class io.grpc.ManagedChannelBuilder
-
Makes the client use TLS.
- useTransportSecurity() - Method in class io.grpc.netty.NettyChannelBuilder
-
Equivalent to using
NettyChannelBuilder.negotiationType(NegotiationType)
withTLS
. - useTransportSecurity(File, File) - Method in class io.grpc.ForwardingServerBuilder
- useTransportSecurity(File, File) - Method in class io.grpc.inprocess.InProcessServerBuilder
- useTransportSecurity(File, File) - Method in class io.grpc.internal.ServerImplBuilder
- useTransportSecurity(File, File) - Method in class io.grpc.netty.NettyServerBuilder
- useTransportSecurity(File, File) - Method in class io.grpc.ServerBuilder
-
Makes the server use TLS.
- useTransportSecurity(File, File) - Method in class io.grpc.servlet.jakarta.ServletServerBuilder
-
Throws
UnsupportedOperationException
. - useTransportSecurity(File, File) - Method in class io.grpc.servlet.ServletServerBuilder
-
Throws
UnsupportedOperationException
. - useTransportSecurity(InputStream, InputStream) - Method in class io.grpc.ForwardingServerBuilder
- useTransportSecurity(InputStream, InputStream) - Method in class io.grpc.netty.NettyServerBuilder
- useTransportSecurity(InputStream, InputStream) - Method in class io.grpc.ServerBuilder
-
Makes the server use TLS.
- usingCustomScheduler - Variable in class io.grpc.servlet.jakarta.ServletServerBuilder
- usingCustomScheduler - Variable in class io.grpc.servlet.ServletServerBuilder
- usingExecutorResource - Variable in class io.grpc.internal.DnsNameResolver
-
True if using an executor resource that should be released after use.
- usingFallbackBackends - Variable in class io.grpc.grpclb.GrpclbState
- Using JUnit TestRule - Search tag in class io.grpc.inprocess.InProcessServerBuilder
- Section
- usingPre4_1_111_Netty - Static variable in class io.grpc.netty.GrpcHttp2ConnectionHandler
- usingPre4_1_111_Netty() - Static method in class io.grpc.netty.GrpcHttp2ConnectionHandler
- utilizationMetrics - Variable in class io.grpc.services.CallMetricRecorder
- utilizationMetrics - Variable in class io.grpc.services.MetricReport
- Utils - Class in io.grpc.netty
-
Common utility methods.
- Utils() - Constructor for class io.grpc.netty.Utils
- Utils.ByteBufAllocatorPreferDirectHolder - Class in io.grpc.netty
- Utils.ByteBufAllocatorPreferHeapHolder - Class in io.grpc.netty
- Utils.DefaultEventLoopGroupResource - Class in io.grpc.netty
- Utils.EventLoopGroupType - Enum in io.grpc.netty
- Utils.FlowControlReader - Class in io.grpc.netty
V
- VALID_HOST_FIELD_NUMBER - Static variable in class io.grpc.reflection.v1.ServerReflectionResponse
- VALID_HOST_FIELD_NUMBER - Static variable in class io.grpc.reflection.v1alpha.ServerReflectionResponse
- VALID_T_CHARS - Static variable in class io.grpc.Metadata.Key
-
Valid characters for field names as defined in RFC7230 and RFC5234.
- VALID_TARGETS_FIELD_NUMBER - Static variable in class io.grpc.lookup.v1.RouteLookupConfig
- validateGeneration(int) - Static method in class io.grpc.Context
-
If the ancestry chain length is unreasonably long, then print an error to the log and record the stack trace.
- validateInitialMetadata(Metadata) - Method in class io.grpc.internal.Http2ClientStreamTransportState
-
Inspect initial headers to make sure they conform to HTTP and gRPC, returning a
Status
on failure. - validateMethodNames(String, Collection<MethodDescriptor<?, ?>>) - Static method in class io.grpc.ServiceDescriptor
- validateName(AsciiString) - Method in class io.grpc.netty.GrpcHttp2HeadersUtils.GrpcHttp2InboundHeaders
- validateName(String, boolean) - Static method in class io.grpc.Metadata.Key
- validatePath(String) - Static method in class io.grpc.internal.SpiffeUtil
- validatePathSegment(String) - Static method in class io.grpc.internal.SpiffeUtil
- validateTrustDomain(String) - Static method in class io.grpc.internal.SpiffeUtil
- Valid characters in key names - Search tag in class io.grpc.Metadata.Key
- Section
- validHost_ - Variable in class io.grpc.reflection.v1.ServerReflectionResponse.Builder
- validHost_ - Variable in class io.grpc.reflection.v1.ServerReflectionResponse
- validHost_ - Variable in class io.grpc.reflection.v1alpha.ServerReflectionResponse.Builder
- validHost_ - Variable in class io.grpc.reflection.v1alpha.ServerReflectionResponse
- validTargets_ - Variable in class io.grpc.lookup.v1.RouteLookupConfig.Builder
- validTargets_ - Variable in class io.grpc.lookup.v1.RouteLookupConfig
- value - Variable in enum io.grpc.binarylog.v1.Address.Type
- value - Variable in enum io.grpc.binarylog.v1.GrpcLogEntry.EventType
- value - Variable in enum io.grpc.binarylog.v1.GrpcLogEntry.Logger
- value - Variable in enum io.grpc.binarylog.v1.GrpcLogEntry.PayloadCase
- value - Variable in enum io.grpc.channelz.v1.Address.AddressCase
- value - Variable in enum io.grpc.channelz.v1.ChannelConnectivityState.State
- value - Variable in enum io.grpc.channelz.v1.ChannelTraceEvent.ChildRefCase
- value - Variable in enum io.grpc.channelz.v1.ChannelTraceEvent.Severity
- value - Variable in enum io.grpc.channelz.v1.Security.ModelCase
- value - Variable in enum io.grpc.channelz.v1.Security.Tls.CipherSuiteCase
- value - Variable in enum io.grpc.health.v1.HealthCheckResponse.ServingStatus
- value - Variable in class io.grpc.internal.AtomicBackoff
- value - Variable in enum io.grpc.lb.v1.LoadBalanceRequest.LoadBalanceRequestTypeCase
- value - Variable in enum io.grpc.lb.v1.LoadBalanceResponse.LoadBalanceResponseTypeCase
- value - Variable in enum io.grpc.lookup.v1.RouteLookupRequest.Reason
- value - Variable in class io.grpc.Metadata.LazyValue
- value - Variable in class io.grpc.netty.GrpcHttp2OutboundHeaders.Itr
- value - Variable in class io.grpc.PersistentHashArrayMappedTrie.Leaf
- value - Variable in enum io.grpc.reflection.v1.ServerReflectionRequest.MessageRequestCase
- value - Variable in enum io.grpc.reflection.v1.ServerReflectionResponse.MessageResponseCase
- value - Variable in enum io.grpc.reflection.v1alpha.ServerReflectionRequest.MessageRequestCase
- value - Variable in enum io.grpc.reflection.v1alpha.ServerReflectionResponse.MessageResponseCase
- value - Variable in class io.grpc.rls.LinkedHashLruCache.SizedValue
- value - Variable in enum io.grpc.Status.Code
- value - Variable in class io.grpc.StatusOr
- value - Variable in class io.grpc.stub.ClientCalls.UnaryStreamToFuture
- value() - Element in annotation type io.grpc.ExperimentalApi
-
Context information such as links to discussion thread, tracking issue etc.
- value() - Method in class io.grpc.internal.AtomicLongCounter
- 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.
- value(int) - Method in class io.grpc.Metadata
- value(int, byte[]) - Method in class io.grpc.Metadata
- value(int, Object) - Method in class io.grpc.Metadata
- value_ - Variable in class io.grpc.binarylog.v1.MetadataEntry.Builder
- value_ - Variable in class io.grpc.binarylog.v1.MetadataEntry
- value_ - Variable in class io.grpc.channelz.v1.Address.OtherAddress.Builder
- value_ - Variable in class io.grpc.channelz.v1.Address.OtherAddress
- value_ - Variable in class io.grpc.channelz.v1.Security.OtherSecurity.Builder
- value_ - Variable in class io.grpc.channelz.v1.Security.OtherSecurity
- value_ - Variable in class io.grpc.channelz.v1.SocketOption.Builder
- value_ - Variable in class io.grpc.channelz.v1.SocketOption
- VALUE_FIELD_NUMBER - Static variable in class io.grpc.binarylog.v1.MetadataEntry
- VALUE_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.Address.OtherAddress
- VALUE_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.Security.OtherSecurity
- VALUE_FIELD_NUMBER - Static variable in class io.grpc.channelz.v1.SocketOption
- valueAsBytes(int) - Method in class io.grpc.Metadata
- valueAsBytesOrStream(int) - Method in class io.grpc.Metadata
- valueAscii - Variable in enum io.grpc.Status.Code
- valueAscii() - Method in enum io.grpc.Status.Code
- valueAsT(int, Metadata.Key<T>) - Method in class io.grpc.Metadata
- valueBuilder_ - Variable in class io.grpc.channelz.v1.Address.OtherAddress.Builder
- valueBuilder_ - Variable in class io.grpc.channelz.v1.Security.OtherSecurity.Builder
- valueIterator(CharSequence) - Method in class io.grpc.netty.AbstractHttp2Headers
- valueOf(int) - Static method in enum io.grpc.binarylog.v1.Address.Type
-
Deprecated.
- valueOf(int) - Static method in enum io.grpc.binarylog.v1.GrpcLogEntry.EventType
-
Deprecated.
- valueOf(int) - Static method in enum io.grpc.binarylog.v1.GrpcLogEntry.Logger
-
Deprecated.
- valueOf(int) - Static method in enum io.grpc.binarylog.v1.GrpcLogEntry.PayloadCase
-
Deprecated.
- valueOf(int) - Static method in enum io.grpc.channelz.v1.Address.AddressCase
-
Deprecated.
- valueOf(int) - Static method in enum io.grpc.channelz.v1.ChannelConnectivityState.State
-
Deprecated.
- valueOf(int) - Static method in enum io.grpc.channelz.v1.ChannelTraceEvent.ChildRefCase
-
Deprecated.
- valueOf(int) - Static method in enum io.grpc.channelz.v1.ChannelTraceEvent.Severity
-
Deprecated.
- valueOf(int) - Static method in enum io.grpc.channelz.v1.Security.ModelCase
-
Deprecated.
- valueOf(int) - Static method in enum io.grpc.channelz.v1.Security.Tls.CipherSuiteCase
-
Deprecated.
- valueOf(int) - Static method in enum io.grpc.health.v1.HealthCheckResponse.ServingStatus
-
Deprecated.
- valueOf(int) - Static method in enum io.grpc.lb.v1.LoadBalanceRequest.LoadBalanceRequestTypeCase
-
Deprecated.
- valueOf(int) - Static method in enum io.grpc.lb.v1.LoadBalanceResponse.LoadBalanceResponseTypeCase
-
Deprecated.
- valueOf(int) - Static method in enum io.grpc.lookup.v1.RouteLookupRequest.Reason
-
Deprecated.
- valueOf(int) - Static method in enum io.grpc.reflection.v1.ServerReflectionRequest.MessageRequestCase
-
Deprecated.
- valueOf(int) - Static method in enum io.grpc.reflection.v1.ServerReflectionResponse.MessageResponseCase
-
Deprecated.
- valueOf(int) - Static method in enum io.grpc.reflection.v1alpha.ServerReflectionRequest.MessageRequestCase
-
Deprecated.
- valueOf(int) - Static method in enum io.grpc.reflection.v1alpha.ServerReflectionResponse.MessageResponseCase
-
Deprecated.
- valueOf(Descriptors.EnumValueDescriptor) - Static method in enum io.grpc.binarylog.v1.Address.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(Descriptors.EnumValueDescriptor) - Static method in enum io.grpc.binarylog.v1.GrpcLogEntry.EventType
-
Returns the enum constant of this type with the specified name.
- valueOf(Descriptors.EnumValueDescriptor) - Static method in enum io.grpc.binarylog.v1.GrpcLogEntry.Logger
-
Returns the enum constant of this type with the specified name.
- valueOf(Descriptors.EnumValueDescriptor) - Static method in enum io.grpc.channelz.v1.ChannelConnectivityState.State
-
Returns the enum constant of this type with the specified name.
- valueOf(Descriptors.EnumValueDescriptor) - Static method in enum io.grpc.channelz.v1.ChannelTraceEvent.Severity
-
Returns the enum constant of this type with the specified name.
- valueOf(Descriptors.EnumValueDescriptor) - Static method in enum io.grpc.health.v1.HealthCheckResponse.ServingStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(Descriptors.EnumValueDescriptor) - Static method in enum io.grpc.lookup.v1.RouteLookupRequest.Reason
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.grpc.binarylog.v1.Address.Type
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.grpc.binarylog.v1.GrpcLogEntry.EventType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.grpc.binarylog.v1.GrpcLogEntry.Logger
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.grpc.binarylog.v1.GrpcLogEntry.PayloadCase
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.grpc.ChannelLogger.ChannelLogLevel
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.grpc.channelz.v1.Address.AddressCase
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.grpc.channelz.v1.ChannelConnectivityState.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.grpc.channelz.v1.ChannelTraceEvent.ChildRefCase
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.grpc.channelz.v1.ChannelTraceEvent.Severity
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.grpc.channelz.v1.Security.ModelCase
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.grpc.channelz.v1.Security.Tls.CipherSuiteCase
-
Returns the enum constant of this type with the specified name.
- 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.Context.DirectExecutor
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.grpc.grpclb.DropType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.grpc.grpclb.GrpclbState.Mode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.grpc.health.v1.HealthCheckResponse.ServingStatus
-
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.DnsNameResolver.JdkAddressResolver
-
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.internal.GzipInflatingBuffer.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.grpc.internal.KeepAliveManager.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.grpc.internal.ManagedChannelImpl.ResolutionState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.grpc.internal.MessageDeframer.State
-
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.lb.v1.LoadBalanceRequest.LoadBalanceRequestTypeCase
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.grpc.lb.v1.LoadBalanceResponse.LoadBalanceResponseTypeCase
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.grpc.lookup.v1.RouteLookupRequest.Reason
-
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.CancelServerStreamCommand.PeerNotify
-
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.netty.Utils.EventLoopGroupType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.grpc.reflection.v1.ServerReflectionRequest.MessageRequestCase
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.grpc.reflection.v1.ServerReflectionResponse.MessageResponseCase
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.grpc.reflection.v1alpha.ServerReflectionRequest.MessageRequestCase
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.grpc.reflection.v1alpha.ServerReflectionResponse.MessageResponseCase
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.grpc.rls.LruCache.EvictionType
-
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.
- valueOf(String) - Static method in enum io.grpc.stub.ClientCalls.StubType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.grpc.stub.InternalClientCalls.StubType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.grpc.TlsChannelCredentials.Feature
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.grpc.TlsServerCredentials.ClientAuth
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.grpc.TlsServerCredentials.Feature
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.grpc.util.AdvancedTlsX509TrustManager.Verification
-
Returns the enum constant of this type with the specified name.
- values - Variable in class io.grpc.netty.GrpcHttp2HeadersUtils.GrpcHttp2InboundHeaders
- values - Variable in class io.grpc.PersistentHashArrayMappedTrie.CollisionLeaf
- values - Variable in class io.grpc.PersistentHashArrayMappedTrie.CompressedIndex
- values() - Static method in enum io.grpc.binarylog.v1.Address.Type
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum io.grpc.binarylog.v1.GrpcLogEntry.EventType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum io.grpc.binarylog.v1.GrpcLogEntry.Logger
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum io.grpc.binarylog.v1.GrpcLogEntry.PayloadCase
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum io.grpc.ChannelLogger.ChannelLogLevel
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum io.grpc.channelz.v1.Address.AddressCase
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum io.grpc.channelz.v1.ChannelConnectivityState.State
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum io.grpc.channelz.v1.ChannelTraceEvent.ChildRefCase
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum io.grpc.channelz.v1.ChannelTraceEvent.Severity
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum io.grpc.channelz.v1.Security.ModelCase
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum io.grpc.channelz.v1.Security.Tls.CipherSuiteCase
-
Returns an array containing the constants of this enum type, in the order they are declared.
- 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.Context.DirectExecutor
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum io.grpc.grpclb.DropType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum io.grpc.grpclb.GrpclbState.Mode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum io.grpc.health.v1.HealthCheckResponse.ServingStatus
-
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.DnsNameResolver.JdkAddressResolver
-
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.internal.GzipInflatingBuffer.State
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum io.grpc.internal.KeepAliveManager.State
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum io.grpc.internal.ManagedChannelImpl.ResolutionState
-
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.State
-
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.lb.v1.LoadBalanceRequest.LoadBalanceRequestTypeCase
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum io.grpc.lb.v1.LoadBalanceResponse.LoadBalanceResponseTypeCase
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum io.grpc.lookup.v1.RouteLookupRequest.Reason
-
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.CancelServerStreamCommand.PeerNotify
-
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.netty.Utils.EventLoopGroupType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum io.grpc.reflection.v1.ServerReflectionRequest.MessageRequestCase
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum io.grpc.reflection.v1.ServerReflectionResponse.MessageResponseCase
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum io.grpc.reflection.v1alpha.ServerReflectionRequest.MessageRequestCase
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum io.grpc.reflection.v1alpha.ServerReflectionResponse.MessageResponseCase
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Method in class io.grpc.rls.LinkedHashLruCache
-
Returns shallow copied values in the cache.
- values() - Static method in enum io.grpc.rls.LruCache.EvictionType
-
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.
- values() - Static method in enum io.grpc.stub.ClientCalls.StubType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum io.grpc.stub.InternalClientCalls.StubType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum io.grpc.TlsChannelCredentials.Feature
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum io.grpc.TlsServerCredentials.ClientAuth
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum io.grpc.TlsServerCredentials.Feature
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum io.grpc.util.AdvancedTlsX509TrustManager.Verification
-
Returns an array containing the constants of this enum type, in the order they are declared.
- VALUES - Static variable in enum io.grpc.binarylog.v1.Address.Type
- VALUES - Static variable in enum io.grpc.binarylog.v1.GrpcLogEntry.EventType
- VALUES - Static variable in enum io.grpc.binarylog.v1.GrpcLogEntry.Logger
- VALUES - Static variable in enum io.grpc.channelz.v1.ChannelConnectivityState.State
- VALUES - Static variable in enum io.grpc.channelz.v1.ChannelTraceEvent.Severity
- VALUES - Static variable in enum io.grpc.health.v1.HealthCheckResponse.ServingStatus
- VALUES - Static variable in enum io.grpc.lookup.v1.RouteLookupRequest.Reason
- verification - Variable in class io.grpc.util.AdvancedTlsX509TrustManager.Builder
- verification - Variable in class io.grpc.util.AdvancedTlsX509TrustManager
- Verification() - Constructor for enum io.grpc.util.AdvancedTlsX509TrustManager.Verification
- verifyNotClosed() - Method in class io.grpc.internal.MessageFramer
- verifyPeerCertificate(X509Certificate[], String, Socket) - Method in interface io.grpc.util.AdvancedTlsX509TrustManager.SslSocketAndEnginePeerVerifier
-
Verifies the peer certificate chain.
- verifyPeerCertificate(X509Certificate[], String, SSLEngine) - Method in interface io.grpc.util.AdvancedTlsX509TrustManager.SslSocketAndEnginePeerVerifier
-
Verifies the peer certificate chain.
- verifySize() - Method in class io.grpc.internal.MessageDeframer.SizeEnforcingInputStream
W
- WAIT_FOR_READY_ERROR - Static variable in class io.grpc.internal.SubchannelChannel
- waitAndDrain() - Method in class io.grpc.stub.ClientCalls.ThreadlessExecutor
-
Waits until there is a Runnable, then executes it and all queued Runnables after it.
- waiter - Variable in class io.grpc.stub.ClientCalls.ThreadlessExecutor
- waitForNext() - Method in class io.grpc.stub.ClientCalls.BlockingResponseStream
- waitForReady - Variable in class io.grpc.CallOptions.Builder
- waitForReady - Variable in class io.grpc.CallOptions
-
Opposite to fail fast.
- waitForReady - Variable in class io.grpc.internal.ManagedChannelServiceConfig.MethodInfo
- waitUntilActiveHandler(ChannelHandler, ChannelLogger) - Static method in class io.grpc.netty.InternalProtocolNegotiators
-
Internal version of
ProtocolNegotiators.WaitUntilActiveHandler
. - WaitUntilActiveHandler(ChannelHandler, ChannelLogger) - Constructor for class io.grpc.netty.ProtocolNegotiators.WaitUntilActiveHandler
- wakeUp - Variable in class io.grpc.internal.Rescheduler
- wantsHeaders() - Method in class io.grpc.netty.CancelServerStreamCommand
- WARNING - Enum constant in enum io.grpc.ChannelLogger.ChannelLogLevel
- wasConfiguratorsSet - Variable in class io.grpc.ConfiguratorRegistry
- wasReady - Variable in class io.grpc.stub.ServerCalls.UnaryServerCallHandler.UnaryServerCallListener
- wasSetConfiguratorsCalled() - Method in class io.grpc.ConfiguratorRegistry
- wasSetConfiguratorsCalled() - Static method in class io.grpc.InternalConfiguratorRegistry
- watch(HealthCheckRequest) - Method in class io.grpc.health.v1.HealthGrpc.HealthBlockingStub
-
Performs a watch for the serving status of the requested service.
- watch(HealthCheckRequest, StreamObserver<HealthCheckResponse>) - Method in interface io.grpc.health.v1.HealthGrpc.AsyncService
-
Performs a watch for the serving status of the requested service.
- watch(HealthCheckRequest, StreamObserver<HealthCheckResponse>) - Method in class io.grpc.health.v1.HealthGrpc.HealthStub
-
Performs a watch for the serving status of the requested service.
- watch(HealthCheckRequest, StreamObserver<HealthCheckResponse>) - Method in class io.grpc.protobuf.services.HealthServiceImpl
- watchers - Variable in class io.grpc.protobuf.services.HealthServiceImpl
- watchLock - Variable in class io.grpc.protobuf.services.HealthServiceImpl
- whitespace - Static variable in class io.grpc.internal.JndiResourceResolverFactory.JndiResourceResolver
- winningSubstream - Variable in class io.grpc.internal.RetriableStream.State
-
Null until committed.
- with(Decompressor, boolean) - Method in class io.grpc.DecompressorRegistry
-
Registers a decompressor for both decompression and message encoding negotiation.
- withAttributes(Attributes) - Method in class io.grpc.netty.ProtocolNegotiationEvent
- withAttributes(ProtocolNegotiationEvent, Attributes) - Static method in class io.grpc.netty.InternalProtocolNegotiationEvent
- 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. - withCallCredentials(CallCredentials) - Method in class io.grpc.netty.ProtocolNegotiators.FromChannelCredentialsResult
- withCallCredentials(CallCredentials) - Method in class io.grpc.stub.AbstractStub
-
Returns a new stub that uses the given call credentials.
- 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
-
Deprecated.
- withChildOption(ChannelOption<T>, T) - Method in class io.grpc.netty.NettyServerBuilder
-
Specifies a child channel option.
- withCompression(String) - Method in class io.grpc.CallOptions
-
Sets the compression to use for the call.
- withCompression(String) - Method in class io.grpc.stub.AbstractStub
-
Set's the compressor name to use for the call.
- withDeadline(Deadline) - Method in class io.grpc.CallOptions
-
Returns a new
CallOptions
with the given absolute deadline. - withDeadline(Deadline) - Method in class io.grpc.stub.AbstractStub
-
Returns a new stub with an absolute deadline.
- withDeadline(Deadline, ScheduledExecutorService) - Method in class io.grpc.Context
-
Create a new context which will cancel itself at the given
Deadline
. - withDeadlineAfter(long, TimeUnit) - Method in class io.grpc.CallOptions
-
Returns a new
CallOptions
with a deadline that is after the givenduration
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. - withDeadlineAfter(long, TimeUnit, ScheduledExecutorService) - Method in class io.grpc.Context
-
Create a new context which will cancel itself 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
-
Returns a new
CallOptions
withexecutor
to be used instead of the default executor specified withManagedChannelBuilder.executor(java.util.concurrent.Executor)
. - withExecutor(Executor) - Method in class io.grpc.stub.AbstractStub
-
Returns a new stub with the given executor that is to be used instead of the default one specified with
ManagedChannelBuilder.executor(java.util.concurrent.Executor)
. - withInterceptors(ClientInterceptor...) - Method in class io.grpc.stub.AbstractStub
-
Returns a new stub that has the given interceptors attached to the underlying channel.
- withMaxInboundMessageSize(int) - Method in class io.grpc.CallOptions
-
Sets the maximum allowed message size acceptable from the remote peer.
- withMaxInboundMessageSize(int) - Method in class io.grpc.stub.AbstractStub
-
Returns a new stub that limits the maximum acceptable message size from a remote peer.
- withMaxOutboundMessageSize(int) - Method in class io.grpc.CallOptions
-
Sets the maximum allowed message size acceptable sent to the remote peer.
- withMaxOutboundMessageSize(int) - Method in class io.grpc.stub.AbstractStub
-
Returns a new stub that limits the maximum acceptable message size to send a remote peer.
- withNoResult() - Static method in class io.grpc.LoadBalancer.PickResult
-
No decision could be made.
- withOnReadyThreshold(int) - Method in class io.grpc.CallOptions
-
Specifies how many bytes must be queued before the call is considered not ready to send more messages.
- withOnReadyThreshold(int) - Method in class io.grpc.stub.AbstractStub
-
Returns a new stub that limits the maximum number of bytes per stream in the queue.
- withOption(CallOptions.Key<T>, T) - Method in class io.grpc.CallOptions
-
Sets a custom option.
- withOption(CallOptions.Key<T>, T) - Method in class io.grpc.stub.AbstractStub
-
Sets a custom option to be passed to client interceptors on the channel
ClientInterceptor
via the CallOptions parameter. - withOption(ChannelOption<T>, T) - Method in class io.grpc.netty.NettyChannelBuilder
-
Specifies a channel option.
- withOption(ChannelOption<T>, T) - Method in class io.grpc.netty.NettyServerBuilder
-
Specifies a channel option.
- withoutBearerTokens() - Method in class io.grpc.ChannelCredentials
-
Returns the ChannelCredentials stripped of its CallCredentials.
- withoutBearerTokens() - Method in class io.grpc.ChoiceChannelCredentials
- withoutBearerTokens() - Method in class io.grpc.CompositeChannelCredentials
- withoutBearerTokens() - Method in class io.grpc.InsecureChannelCredentials
- withoutBearerTokens() - Method in class io.grpc.internal.ManagedChannelImpl.LbHelperImpl.DefaultChannelCreds
- withoutBearerTokens() - Method in class io.grpc.netty.NettyChannelCredentials
- withoutBearerTokens() - Method in class io.grpc.TlsChannelCredentials
- withoutWaitForReady() - Method in class io.grpc.CallOptions
-
Disables 'wait for ready' feature for the call.
- withPicker(LoadBalancer.SubchannelPicker) - Method in class io.grpc.internal.DelayedClientTransport.PickerState
- withReadyAndDrained(boolean) - Method in class io.grpc.servlet.AsyncServletOutputStreamWriter.WriteState
-
Only
onWritePossible()
can set readyAndDrained to true, and onlyrunOrBuffer()
can set it to false. - withReadyAndDrained(boolean) - Method in class io.grpc.servlet.jakarta.AsyncServletOutputStreamWriter.WriteState
-
Only
onWritePossible()
can set readyAndDrained to true, and onlyrunOrBuffer()
can set it to false. - withReason(NettyServerStream.TransportState, Status) - Static method in class io.grpc.netty.CancelServerStreamCommand
- withReset(NettyServerStream.TransportState, Status) - Static method in class io.grpc.netty.CancelServerStreamCommand
- withSecurity(InternalChannelz.Security) - Method in class io.grpc.netty.ProtocolNegotiationEvent
- withSecurity(ProtocolNegotiationEvent, InternalChannelz.Security) - Static method in class io.grpc.netty.InternalProtocolNegotiationEvent
- withServerCallHandler(ServerCallHandler<ReqT, RespT>) - Method in class io.grpc.ServerMethodDefinition
-
Create a new method definition with a different call handler.
- withShutdownStatus(Status) - Method in class io.grpc.internal.DelayedClientTransport.PickerState
- withStreamTracerFactory(ClientStreamTracer.Factory) - Method in class io.grpc.CallOptions
-
Returns a new
CallOptions
with aClientStreamTracerFactory
in addition to the existing factories. - withSubchannel(LoadBalancer.Subchannel) - Static method in class io.grpc.LoadBalancer.PickResult
-
Equivalent to
withSubchannel(subchannel, null)
. - withSubchannel(LoadBalancer.Subchannel, ClientStreamTracer.Factory) - Static method in class io.grpc.LoadBalancer.PickResult
-
A decision to proceed the RPC on a Subchannel.
- 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.
- withValues(Context.Key<V1>, V1, Context.Key<V2>, V2, Context.Key<V3>, V3, Context.Key<V4>, V4) - Method in class io.grpc.Context
-
Create a new context with the given key value set.
- withWaitForReady() - Method in class io.grpc.CallOptions
-
Enables 'wait for ready' for the call.
- withWaitForReady() - Method in class io.grpc.stub.AbstractStub
-
Returns a new stub that uses 'wait for ready' for the call.
- workerEventLoopGroup(EventLoopGroup) - Method in class io.grpc.netty.NettyServerBuilder
-
Provides the worker EventGroupLoop to the server.
- workerEventLoopGroupPool - Variable in class io.grpc.netty.NettyServerBuilder
- workerEventLoopGroupPool(ObjectPool<? extends EventLoopGroup>) - Method in class io.grpc.netty.NettyServerBuilder
- workerGroup - Variable in class io.grpc.netty.NettyServer
- workerGroupPool - Variable in class io.grpc.netty.NettyServer
- wrap(byte[]) - Static method in class io.grpc.internal.ReadableBuffers
-
Shortcut for
wrap(bytes, 0, bytes.length
. - wrap(byte[], int, int) - Static method in class io.grpc.internal.ReadableBuffers
-
Creates a new
ReadableBuffer
that is backed by the given byte array. - wrap(Runnable) - Method in class io.grpc.Context
-
Wrap a
Runnable
so that it executes with this context as theContext.current()
context. - wrap(ByteBuffer) - Static method in class io.grpc.internal.ReadableBuffers
-
Creates a new
ReadableBuffer
that is backed by the givenByteBuffer
. - wrap(Callable<C>) - Method in class io.grpc.Context
-
Wrap a
Callable
so that it executes with this context as theContext.current()
context. - wrapAndAddMethod(ServerServiceDefinition.Builder, ServerMethodDefinition<ReqT, RespT>, List<? extends ServerInterceptor>) - Static method in class io.grpc.ServerInterceptors
- wrapChannel(Channel) - Method in class io.grpc.BinaryLog
- wrapChannel(Channel) - Method in class io.grpc.protobuf.services.BinaryLogProvider
-
Wraps a channel to provide binary logging on
ClientCall
s as needed. - wrapClientInterceptor(ClientInterceptor, MethodDescriptor.Marshaller<ReqT>, MethodDescriptor.Marshaller<RespT>) - Static method in class io.grpc.InternalClientInterceptors
- wrapClientInterceptor(ClientInterceptor, MethodDescriptor.Marshaller<WReqT>, MethodDescriptor.Marshaller<WRespT>) - Static method in class io.grpc.ClientInterceptors
-
Creates a new ClientInterceptor that transforms requests into
WReqT
and responses intoWRespT
before passing them into theinterceptor
. - wrapHandler(ServerCallHandler<OReqT, ORespT>, MethodDescriptor<OReqT, ORespT>, MethodDescriptor<WReqT, WRespT>) - Static method in class io.grpc.ServerInterceptors
- wrapMethod(ServerStream, ServerMethodDefinition<ReqT, RespT>, StatsTraceContext) - Method in class io.grpc.internal.ServerImpl.ServerTransportListenerImpl
-
Never returns
null
. - wrapMethod(ServerMethodDefinition<OReqT, ORespT>, MethodDescriptor<WReqT, WRespT>) - Static method in class io.grpc.ServerInterceptors
- wrapMethod(ServerMethodDefinition<OrigReqT, OrigRespT>, MethodDescriptor<WrapReqT, WrapRespT>) - Static method in class io.grpc.InternalServerInterceptors
- wrapMethodDefinition(ServerMethodDefinition<ReqT, RespT>) - Method in class io.grpc.BinaryLog
- wrapMethodDefinition(ServerMethodDefinition<ReqT, RespT>) - Method in class io.grpc.protobuf.services.BinaryLogProvider
-
Wraps a
ServerMethodDefinition
such that it performs binary logging if needed. - WrappingMetadataApplier(CallCredentials.RequestInfo, Executor, CallCredentials.MetadataApplier, Context) - Constructor for class io.grpc.CompositeCallCredentials.WrappingMetadataApplier
- 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.
- writableBytes() - Method in class io.grpc.netty.NettyWritableBuffer
- writableBytes() - Method in class io.grpc.servlet.jakarta.ServletServerStream.ByteArrayWritableBuffer
- writableBytes() - Method in class io.grpc.servlet.ServletServerStream.ByteArrayWritableBuffer
- write(byte) - Method in interface io.grpc.internal.WritableBuffer
-
Appends a single byte to the buffer.
- write(byte) - Method in class io.grpc.netty.NettyWritableBuffer
- write(byte) - Method in class io.grpc.servlet.jakarta.ServletServerStream.ByteArrayWritableBuffer
- write(byte) - Method in class io.grpc.servlet.ServletServerStream.ByteArrayWritableBuffer
- write(byte[], int, int) - Method in class io.grpc.internal.MessageFramer.BufferChainOutputStream
- write(byte[], int, int) - Method in class io.grpc.internal.MessageFramer.OutputStreamAdapter
- write(byte[], int, int) - Method in interface io.grpc.internal.WritableBuffer
-
Appends
length
bytes to the buffer from the source array starting atsrcIndex
. - write(byte[], int, int) - Method in class io.grpc.netty.NettyWritableBuffer
- write(byte[], int, int) - Method in class io.grpc.servlet.jakarta.ServletServerStream.ByteArrayWritableBuffer
- write(byte[], int, int) - Method in class io.grpc.servlet.ServletServerStream.ByteArrayWritableBuffer
- write(int) - Method in class io.grpc.internal.MessageFramer.BufferChainOutputStream
-
This is slow, don't call it.
- write(int) - Method in class io.grpc.internal.MessageFramer.OutputStreamAdapter
-
This is slow, don't call it.
- write(MessageLite) - Method in interface io.grpc.protobuf.services.BinaryLogSink
-
Writes the
message
to the destination. - write(MessageLite) - Method in class io.grpc.protobuf.services.TempFileSink
- write(ChannelHandlerContext, Object, ChannelPromise) - Method in class io.grpc.netty.NettyClientHandler
-
Handler for commands sent from the stream.
- write(ChannelHandlerContext, Object, ChannelPromise) - Method in class io.grpc.netty.NettyServerHandler
-
Handler for commands sent from the stream.
- write(ChannelHandlerContext, Object, ChannelPromise) - Method in class io.grpc.netty.WriteBufferingAndExceptionHandler
-
Buffers the write until either
WriteBufferingAndExceptionHandler.writeBufferedAndRemove(ChannelHandlerContext)
is called, or we have somehow failed. - writeAction - Variable in class io.grpc.servlet.AsyncServletOutputStreamWriter
- writeAction - Variable in class io.grpc.servlet.jakarta.AsyncServletOutputStreamWriter
- writeBufferChain(MessageFramer.BufferChainOutputStream, boolean) - Method in class io.grpc.internal.MessageFramer
-
Write a message that has been serialized to a sequence of buffers.
- writeBufferedAndRemove(ChannelHandlerContext) - Method in class io.grpc.netty.WriteBufferingAndExceptionHandler
- WriteBufferingAndExceptionHandler - Class in io.grpc.netty
-
Buffers all writes until either
WriteBufferingAndExceptionHandler.writeBufferedAndRemove(ChannelHandlerContext)
orWriteBufferingAndExceptionHandler.failWrites(Throwable)
is called. - WriteBufferingAndExceptionHandler(ChannelHandler) - Constructor for class io.grpc.netty.WriteBufferingAndExceptionHandler
- WriteBufferingAndExceptionHandler.ChannelWrite - Class in io.grpc.netty
- writeBufferingAndRemove(Channel) - Static method in class io.grpc.netty.InternalWriteBufferingAndExceptionHandlerUtils
-
Writes buffered data and removes
WriteBufferingAndExceptionHandler
fromChannelPipeline
. - writeBufferingAndRemove(Channel) - Static method in class io.grpc.netty.NettyClientHandler
- writeBytes(byte[], int) - Method in class io.grpc.servlet.AsyncServletOutputStreamWriter
-
Called from application thread.
- writeBytes(byte[], int) - Method in class io.grpc.servlet.jakarta.AsyncServletOutputStreamWriter
-
Called from application thread.
- writeChain - Variable in class io.grpc.servlet.AsyncServletOutputStreamWriter
-
New write actions will be buffered into this queue if the servlet output stream is not ready or the queue is not drained.
- writeChain - Variable in class io.grpc.servlet.jakarta.AsyncServletOutputStreamWriter
-
New write actions will be buffered into this queue if the servlet output stream is not ready or the queue is not drained.
- writeCompressed(InputStream, int) - Method in class io.grpc.internal.MessageFramer
- writeData(ChannelHandlerContext, int, ByteBuf, int, boolean, ChannelPromise) - Method in class io.grpc.netty.NettyClientHandler.PingCountingFrameWriter
- writeData(ChannelHandlerContext, int, ByteBuf, int, boolean, ChannelPromise) - Method in class io.grpc.netty.NettyServerHandler.WriteMonitoringFrameWriter
- 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, boolean, int) - Method in class io.grpc.netty.NettyClientStream.Sink
- writeFrame(WritableBuffer, boolean, int) - Method in interface io.grpc.internal.AbstractServerStream.Sink
-
Sends an outbound frame to the remote end point.
- writeFrame(WritableBuffer, boolean, int) - Method in class io.grpc.netty.NettyServerStream.Sink
- writeFrame(WritableBuffer, boolean, int) - Method in class io.grpc.servlet.jakarta.ServletServerStream.Sink
- writeFrame(WritableBuffer, boolean, int) - Method in class io.grpc.servlet.ServletServerStream.Sink
- writeFrameInternal(WritableBuffer, boolean, boolean, int) - Method in class io.grpc.netty.NettyClientStream.Sink
- writeHeaders(Metadata, boolean) - Method in class io.grpc.inprocess.InProcessTransport.InProcessStream.InProcessServerStream
- writeHeaders(Metadata, boolean) - Method in interface io.grpc.internal.AbstractServerStream.Sink
-
Sends response headers to the remote end point.
- writeHeaders(Metadata, boolean) - Method in class io.grpc.internal.AbstractServerStream
- writeHeaders(Metadata, boolean) - Method in interface io.grpc.internal.ServerStream
-
Writes custom metadata as headers on the response stream sent to the client.
- writeHeaders(Metadata, boolean) - Method in class io.grpc.netty.NettyServerStream.Sink
- writeHeaders(Metadata, boolean) - Method in class io.grpc.servlet.jakarta.ServletServerStream.Sink
- writeHeaders(Metadata, boolean) - Method in class io.grpc.servlet.ServletServerStream.Sink
- writeHeaders(Metadata, byte[]) - Method in interface io.grpc.internal.AbstractClientStream.Sink
-
Sends the request headers to the remote end point.
- writeHeaders(Metadata, byte[]) - Method in class io.grpc.netty.NettyClientStream.Sink
- writeHeaders(ChannelHandlerContext, int, Http2Headers, int, boolean, ChannelPromise) - Method in class io.grpc.netty.NettyClientHandler.PingCountingFrameWriter
- writeHeaders(ChannelHandlerContext, int, Http2Headers, int, boolean, ChannelPromise) - Method in class io.grpc.netty.NettyServerHandler.WriteMonitoringFrameWriter
- writeHeaders(ChannelHandlerContext, int, Http2Headers, int, short, boolean, int, boolean, ChannelPromise) - Method in class io.grpc.netty.NettyClientHandler.PingCountingFrameWriter
- writeHeaders(ChannelHandlerContext, int, Http2Headers, int, short, boolean, int, boolean, ChannelPromise) - Method in class io.grpc.netty.NettyServerHandler.WriteMonitoringFrameWriter
- writeHeadersInternal(Metadata, byte[]) - Method in class io.grpc.netty.NettyClientStream.Sink
- writeHeadersToServletResponse(Metadata) - Method in class io.grpc.servlet.jakarta.ServletServerStream
- writeHeadersToServletResponse(Metadata) - Method in class io.grpc.servlet.ServletServerStream
- writeKnownLengthUncompressed(InputStream, int) - Method in class io.grpc.internal.MessageFramer
-
Write an unserialized message with a known length, uncompressed.
- writeMessage(InputStream) - Method in class io.grpc.inprocess.InProcessTransport.InProcessStream.InProcessClientStream
- writeMessage(InputStream) - Method in class io.grpc.inprocess.InProcessTransport.InProcessStream.InProcessServerStream
- writeMessage(InputStream) - Method in class io.grpc.internal.AbstractStream
- writeMessage(InputStream) - Method in class io.grpc.internal.DelayedStream
- writeMessage(InputStream) - Method in class io.grpc.internal.ForwardingClientStream
- writeMessage(InputStream) - Method in class io.grpc.internal.NoopClientStream
- writeMessage(InputStream) - Method in class io.grpc.internal.RetriableStream
-
Do not use it directly.
- writeMessage(InputStream) - Method in interface io.grpc.internal.Stream
-
Writes a message payload to the remote end-point.
- WriteMonitoringFrameWriter(Http2FrameWriter, KeepAliveEnforcer) - Constructor for class io.grpc.netty.NettyServerHandler.WriteMonitoringFrameWriter
- writePayload(InputStream) - Method in class io.grpc.internal.AbstractClientStream.GetFramer
- 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.
- writePing(ChannelHandlerContext, boolean, long, ChannelPromise) - Method in class io.grpc.netty.Http2ControlFrameLimitEncoder
- writePing(ChannelHandlerContext, boolean, long, ChannelPromise) - Method in class io.grpc.netty.NettyClientHandler.PingCountingFrameWriter
- writeQueue - Variable in class io.grpc.netty.NettyClientStream
- writeQueue - Variable in class io.grpc.netty.NettyServerStream
- WriteQueue - Class in io.grpc.netty
-
A queue of pending writes to a
Channel
that is flushed as a single unit. - WriteQueue(Channel) - Constructor for class io.grpc.netty.WriteQueue
- WriteQueue.AbstractQueuedCommand - Class in io.grpc.netty
- WriteQueue.QueuedCommand - Interface in io.grpc.netty
-
Simple wrapper type around a command and its optional completion listener.
- WriteQueue.RunnableCommand - Class in io.grpc.netty
- writer - Variable in class io.grpc.protobuf.services.BinlogHelper
- writer - Variable in class io.grpc.servlet.jakarta.ServletServerStream
- writer - Variable in class io.grpc.servlet.ServletServerStream
- writeRaw(byte[], int, int) - Method in class io.grpc.internal.MessageFramer
- writeRstStream(ChannelHandlerContext, int, long, ChannelPromise) - Method in class io.grpc.netty.Http2ControlFrameLimitEncoder
- writeSettingsAck(ChannelHandlerContext, ChannelPromise) - Method in class io.grpc.netty.Http2ControlFrameLimitEncoder
- writeState - Variable in class io.grpc.servlet.AsyncServletOutputStreamWriter
-
Memory boundary for write actions.
- writeState - Variable in class io.grpc.servlet.jakarta.AsyncServletOutputStreamWriter
-
Memory boundary for write actions.
- WriteState(boolean) - Constructor for class io.grpc.servlet.AsyncServletOutputStreamWriter.WriteState
- WriteState(boolean) - Constructor for class io.grpc.servlet.jakarta.AsyncServletOutputStreamWriter.WriteState
- writeTo(CodedOutputStream) - Method in class io.grpc.binarylog.v1.Address
- writeTo(CodedOutputStream) - Method in class io.grpc.binarylog.v1.ClientHeader
- writeTo(CodedOutputStream) - Method in class io.grpc.binarylog.v1.GrpcLogEntry
- writeTo(CodedOutputStream) - Method in class io.grpc.binarylog.v1.Message
- writeTo(CodedOutputStream) - Method in class io.grpc.binarylog.v1.Metadata
- writeTo(CodedOutputStream) - Method in class io.grpc.binarylog.v1.MetadataEntry
- writeTo(CodedOutputStream) - Method in class io.grpc.binarylog.v1.ServerHeader
- writeTo(CodedOutputStream) - Method in class io.grpc.binarylog.v1.Trailer
- writeTo(CodedOutputStream) - Method in class io.grpc.channelz.v1.Address.OtherAddress
- writeTo(CodedOutputStream) - Method in class io.grpc.channelz.v1.Address.TcpIpAddress
- writeTo(CodedOutputStream) - Method in class io.grpc.channelz.v1.Address.UdsAddress
- writeTo(CodedOutputStream) - Method in class io.grpc.channelz.v1.Address
- writeTo(CodedOutputStream) - Method in class io.grpc.channelz.v1.Channel
- writeTo(CodedOutputStream) - Method in class io.grpc.channelz.v1.ChannelConnectivityState
- writeTo(CodedOutputStream) - Method in class io.grpc.channelz.v1.ChannelData
- writeTo(CodedOutputStream) - Method in class io.grpc.channelz.v1.ChannelRef
- writeTo(CodedOutputStream) - Method in class io.grpc.channelz.v1.ChannelTrace
- writeTo(CodedOutputStream) - Method in class io.grpc.channelz.v1.ChannelTraceEvent
- writeTo(CodedOutputStream) - Method in class io.grpc.channelz.v1.GetChannelRequest
- writeTo(CodedOutputStream) - Method in class io.grpc.channelz.v1.GetChannelResponse
- writeTo(CodedOutputStream) - Method in class io.grpc.channelz.v1.GetServerRequest
- writeTo(CodedOutputStream) - Method in class io.grpc.channelz.v1.GetServerResponse
- writeTo(CodedOutputStream) - Method in class io.grpc.channelz.v1.GetServerSocketsRequest
- writeTo(CodedOutputStream) - Method in class io.grpc.channelz.v1.GetServerSocketsResponse
- writeTo(CodedOutputStream) - Method in class io.grpc.channelz.v1.GetServersRequest
- writeTo(CodedOutputStream) - Method in class io.grpc.channelz.v1.GetServersResponse
- writeTo(CodedOutputStream) - Method in class io.grpc.channelz.v1.GetSocketRequest
- writeTo(CodedOutputStream) - Method in class io.grpc.channelz.v1.GetSocketResponse
- writeTo(CodedOutputStream) - Method in class io.grpc.channelz.v1.GetSubchannelRequest
- writeTo(CodedOutputStream) - Method in class io.grpc.channelz.v1.GetSubchannelResponse
- writeTo(CodedOutputStream) - Method in class io.grpc.channelz.v1.GetTopChannelsRequest
- writeTo(CodedOutputStream) - Method in class io.grpc.channelz.v1.GetTopChannelsResponse
- writeTo(CodedOutputStream) - Method in class io.grpc.channelz.v1.Security.OtherSecurity
- writeTo(CodedOutputStream) - Method in class io.grpc.channelz.v1.Security.Tls
- writeTo(CodedOutputStream) - Method in class io.grpc.channelz.v1.Security
- writeTo(CodedOutputStream) - Method in class io.grpc.channelz.v1.Server
- writeTo(CodedOutputStream) - Method in class io.grpc.channelz.v1.ServerData
- writeTo(CodedOutputStream) - Method in class io.grpc.channelz.v1.ServerRef
- writeTo(CodedOutputStream) - Method in class io.grpc.channelz.v1.Socket
- writeTo(CodedOutputStream) - Method in class io.grpc.channelz.v1.SocketData
- writeTo(CodedOutputStream) - Method in class io.grpc.channelz.v1.SocketOption
- writeTo(CodedOutputStream) - Method in class io.grpc.channelz.v1.SocketOptionLinger
- writeTo(CodedOutputStream) - Method in class io.grpc.channelz.v1.SocketOptionTcpInfo
- writeTo(CodedOutputStream) - Method in class io.grpc.channelz.v1.SocketOptionTimeout
- writeTo(CodedOutputStream) - Method in class io.grpc.channelz.v1.SocketRef
- writeTo(CodedOutputStream) - Method in class io.grpc.channelz.v1.Subchannel
- writeTo(CodedOutputStream) - Method in class io.grpc.channelz.v1.SubchannelRef
- writeTo(CodedOutputStream) - Method in class io.grpc.health.v1.HealthCheckRequest
- writeTo(CodedOutputStream) - Method in class io.grpc.health.v1.HealthCheckResponse
- writeTo(CodedOutputStream) - Method in class io.grpc.lb.v1.ClientStats
- writeTo(CodedOutputStream) - Method in class io.grpc.lb.v1.ClientStatsPerToken
- writeTo(CodedOutputStream) - Method in class io.grpc.lb.v1.FallbackResponse
- writeTo(CodedOutputStream) - Method in class io.grpc.lb.v1.InitialLoadBalanceRequest
- writeTo(CodedOutputStream) - Method in class io.grpc.lb.v1.InitialLoadBalanceResponse
- writeTo(CodedOutputStream) - Method in class io.grpc.lb.v1.LoadBalanceRequest
- writeTo(CodedOutputStream) - Method in class io.grpc.lb.v1.LoadBalanceResponse
- writeTo(CodedOutputStream) - Method in class io.grpc.lb.v1.Server
- writeTo(CodedOutputStream) - Method in class io.grpc.lb.v1.ServerList
- writeTo(CodedOutputStream) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.ExtraKeys
- writeTo(CodedOutputStream) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder.Name
- writeTo(CodedOutputStream) - Method in class io.grpc.lookup.v1.GrpcKeyBuilder
- writeTo(CodedOutputStream) - Method in class io.grpc.lookup.v1.HttpKeyBuilder
- writeTo(CodedOutputStream) - Method in class io.grpc.lookup.v1.NameMatcher
- writeTo(CodedOutputStream) - Method in class io.grpc.lookup.v1.RouteLookupClusterSpecifier
- writeTo(CodedOutputStream) - Method in class io.grpc.lookup.v1.RouteLookupConfig
- writeTo(CodedOutputStream) - Method in class io.grpc.lookup.v1.RouteLookupRequest
- writeTo(CodedOutputStream) - Method in class io.grpc.lookup.v1.RouteLookupResponse
- writeTo(CodedOutputStream) - Method in class io.grpc.reflection.v1.ErrorResponse
- writeTo(CodedOutputStream) - Method in class io.grpc.reflection.v1.ExtensionNumberResponse
- writeTo(CodedOutputStream) - Method in class io.grpc.reflection.v1.ExtensionRequest
- writeTo(CodedOutputStream) - Method in class io.grpc.reflection.v1.FileDescriptorResponse
- writeTo(CodedOutputStream) - Method in class io.grpc.reflection.v1.ListServiceResponse
- writeTo(CodedOutputStream) - Method in class io.grpc.reflection.v1.ServerReflectionRequest
- writeTo(CodedOutputStream) - Method in class io.grpc.reflection.v1.ServerReflectionResponse
- writeTo(CodedOutputStream) - Method in class io.grpc.reflection.v1.ServiceResponse
- writeTo(CodedOutputStream) - Method in class io.grpc.reflection.v1alpha.ErrorResponse
- writeTo(CodedOutputStream) - Method in class io.grpc.reflection.v1alpha.ExtensionNumberResponse
- writeTo(CodedOutputStream) - Method in class io.grpc.reflection.v1alpha.ExtensionRequest
- writeTo(CodedOutputStream) - Method in class io.grpc.reflection.v1alpha.FileDescriptorResponse
- writeTo(CodedOutputStream) - Method in class io.grpc.reflection.v1alpha.ListServiceResponse
- writeTo(CodedOutputStream) - Method in class io.grpc.reflection.v1alpha.ServerReflectionRequest
- writeTo(CodedOutputStream) - Method in class io.grpc.reflection.v1alpha.ServerReflectionResponse
- writeTo(CodedOutputStream) - Method in class io.grpc.reflection.v1alpha.ServiceResponse
- writeToOutputStream(InputStream, OutputStream) - Static method in class io.grpc.internal.MessageFramer
- writeTrailers(Metadata, boolean, Status) - Method in interface io.grpc.internal.AbstractServerStream.Sink
-
Sends trailers to the remote end point.
- writeTrailers(Metadata, boolean, Status) - Method in class io.grpc.netty.NettyServerStream.Sink
- writeTrailers(Metadata, boolean, Status) - Method in class io.grpc.servlet.jakarta.ServletServerStream.Sink
- writeTrailers(Metadata, boolean, Status) - Method in class io.grpc.servlet.ServletServerStream.Sink
- writeUncompressed(InputStream, int) - Method in class io.grpc.internal.MessageFramer
- writeWindowUpdate(ChannelHandlerContext, int, int, ChannelPromise) - Method in class io.grpc.netty.NettyClientHandler.PingCountingFrameWriter
- writing - Variable in class io.grpc.netty.WriteBufferingAndExceptionHandler
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
ChannelzService
instead.