Uses of Class
io.grpc.Status
-
Packages that use Status Package Description io.grpc The gRPC core public API.io.grpc.grpclb io.grpc.inprocess The in-process transport which is for when a server is in the same process as the client.io.grpc.internal Interfaces and implementations that are internal to gRPC.io.grpc.netty The main transport implementation based on Netty, for both the client and the server.io.grpc.protobuf API for gRPC over Protocol Buffers, including tools for serializing and de-serializing protobuf messages.io.grpc.protobuf.services Service definitions and utilities with protobuf dependency for the pre-defined gRPC services.io.grpc.rls io.grpc.servlet API that implements gRPC server as a servlet.io.grpc.servlet.jakarta API that implements gRPC server as a servlet.io.grpc.stub API for the Stub layer.io.grpc.util Utilities with advanced features in the core layer that user can optionally use. -
-
Uses of Status in io.grpc
Fields in io.grpc declared as Status Modifier and Type Field Description static Status
Status. ABORTED
The operation was aborted, typically due to a concurrency issue like sequencer check failures, transaction aborts, etc.static Status
Status. ALREADY_EXISTS
Some entity that we attempted to create (e.g., file or directory) already exists.static Status
Status. CANCELLED
The operation was cancelled (typically by the caller).static Status
Status. DATA_LOSS
Unrecoverable data loss or corruption.static Status
Status. DEADLINE_EXCEEDED
Deadline expired before operation could complete.private Status
LoadBalancer.ErrorPicker. error
Deprecated.static Status
Status. FAILED_PRECONDITION
Operation was rejected because the system is not in a state required for the operation's execution.static Status
Status. INTERNAL
Internal errors.static Status
Status. INVALID_ARGUMENT
Client specified an invalid argument.static Status
Status. NOT_FOUND
Some requested entity (e.g., file or directory) was not found.static Status
Status. OK
The operation completed successfully.static Status
Status. OUT_OF_RANGE
Operation was attempted past the valid range.static Status
Status. PERMISSION_DENIED
The caller does not have permission to execute the specified operation.static Status
Status. RESOURCE_EXHAUSTED
Some resource has been exhausted, perhaps a per-user quota, or perhaps the entire file system is out of space.private Status
ConnectivityStateInfo. status
private Status
InternalConfigSelector.Result. status
private Status
LoadBalancer.PickResult. status
private Status
NameResolver.ConfigOrError. status
private Status
StatusException. status
private Status
StatusOr. status
private Status
StatusRuntimeException. status
static Status
Status. UNAUTHENTICATED
The request does not have valid authentication credentials for the operation.static Status
Status. UNAVAILABLE
The service is currently unavailable.static Status
Status. UNIMPLEMENTED
Operation is not implemented or not supported/enabled in this service.static Status
Status. UNKNOWN
Unknown error.Fields in io.grpc with type parameters of type Status Modifier and Type Field Description static Metadata.Key<Status>
InternalStatus. CODE_KEY
Key to bind status code to trailing metadata.(package private) static Metadata.Key<Status>
Status. CODE_KEY
Key to bind status code to trailing metadata.private static java.util.List<Status>
Status. STATUS_LIST
Methods in io.grpc that return Status Modifier and Type Method Description Status
LoadBalancer. acceptResolvedAddresses(LoadBalancer.ResolvedAddresses resolvedAddresses)
Accepts newly resolved addresses from the name resolution system.Status
Status. augmentDescription(java.lang.String additionalDetail)
Create a derived instance ofStatus
augmenting the current description with additional detail.static Status
Status. fromCode(Status.Code code)
Return aStatus
given a canonical errorStatus.Code
object.private static Status
Status. fromCodeValue(byte[] asciiCodeValue)
static Status
Status. fromCodeValue(int codeValue)
Return aStatus
given a canonical errorStatus.Code
value.private static Status
Status. fromCodeValueSlow(byte[] asciiCodeValue)
static Status
Status. fromThrowable(java.lang.Throwable t)
Extract an errorStatus
from the causal chain of aThrowable
.Status
NameResolver.ConfigOrError. getError()
Returns error status if exists, otherwise null.Status
ConnectivityStateInfo. getStatus()
Returns the status associated with the state.Status
InternalConfigSelector.Result. getStatus()
Returns the status of the config selection operation.Status
LoadBalancer.PickResult. getStatus()
The status associated with this result.Status
StatusException. getStatus()
Returns the status code as aStatus
object.Status
StatusOr. getStatus()
Returns the status.Status
StatusRuntimeException. getStatus()
Returns the status code as aStatus
object.Status
NameResolver.Listener2. onResult2(NameResolver.ResolutionResult resolutionResult)
Handles updates on resolved addresses and attributes.Status
Status.StatusCodeMarshaller. parseAsciiString(byte[] serialized)
static Status
Contexts. statusFromCancelled(Context context)
Returns theStatus
of a cancelled context ornull
if the context is not cancelled.Status
Status.Code. toStatus()
Returns aStatus
object corresponding to this status code.Status
Status. withCause(java.lang.Throwable cause)
Create a derived instance ofStatus
with the given cause.Status
Status. withDescription(java.lang.String description)
Create a derived instance ofStatus
with the given description.Methods in io.grpc that return types with arguments of type Status Modifier and Type Method Description private static java.util.List<Status>
Status. buildStatusList()
Methods in io.grpc with parameters of type Status Modifier and Type Method Description static StatusRuntimeException
InternalStatus. asRuntimeException(Status status, Metadata trailers, boolean fillInStackTrace)
Create a newStatusRuntimeException
with the internal option of skipping the filling of the stack trace.void
PartialForwardingServerCall. close(Status status, Metadata trailers)
abstract void
ServerCall. close(Status status, Metadata trailers)
Close the call with the provided status.abstract void
CallCredentials.MetadataApplier. fail(Status status)
Called when there has been an error when preparing the headers.void
CompositeCallCredentials.CombiningMetadataApplier. fail(Status status)
void
CompositeCallCredentials.WrappingMetadataApplier. fail(Status status)
static InternalConfigSelector.Result
InternalConfigSelector.Result. forError(Status status)
Creates aResult
with the given error status.(package private) static java.lang.String
Status. formatThrowableMessage(Status status)
static ConnectivityStateInfo
ConnectivityStateInfo. forTransientFailure(Status error)
Returns an instance forTRANSIENT_FAILURE
, associated with an error status.static NameResolver.ConfigOrError
NameResolver.ConfigOrError. fromError(Status status)
Returns aNameResolver.ConfigOrError
for the failure to parse the config.static <T> StatusOr<T>
StatusOr. fromStatus(Status status)
Construct from a non-Ok status.abstract void
LoadBalancer. handleNameResolutionError(Status error)
Handles an error from the name resolution system.void
ClientCall.Listener. onClose(Status status, Metadata trailers)
The ClientCall has been closed.void
PartialForwardingClientCallListener. onClose(Status status, Metadata trailers)
void
NameResolver.Listener. onError(Status error)
Handles an error from the resolver.abstract void
NameResolver.Listener2. onError(Status error)
Handles a name resolving error from the resolver.void
StreamTracer. streamClosed(Status status)
Stream is closed.byte[]
Status.StatusCodeMarshaller. toAsciiString(Status status)
static LoadBalancer.PickResult
LoadBalancer.PickResult. withDrop(Status status)
A decision to fail an RPC immediately.static LoadBalancer.PickResult
LoadBalancer.PickResult. withError(Status error)
A decision to report a connectivity error to the RPC.Constructors in io.grpc with parameters of type Status Constructor Description ConfigOrError(Status status)
ConnectivityStateInfo(ConnectivityState state, Status status)
ErrorPicker(Status error)
Deprecated.PickResult(LoadBalancer.Subchannel subchannel, ClientStreamTracer.Factory streamTracerFactory, Status status, boolean drop)
Result(Status status, java.lang.Object config, ClientInterceptor interceptor)
StatusException(Status status)
Constructs an exception with both a status.StatusException(Status status, Metadata trailers)
Constructs an exception with both a status and trailers.StatusException(Status status, Metadata trailers, boolean fillInStackTrace)
StatusOr(Status status, T value)
StatusRuntimeException(Status status)
Constructs the exception with a status.StatusRuntimeException(Status status, Metadata trailers)
Constructs the exception with both a status and trailers.StatusRuntimeException(Status status, Metadata trailers, boolean fillInStackTrace)
-
Uses of Status in io.grpc.grpclb
Fields in io.grpc.grpclb declared as Status Modifier and Type Field Description (package private) static Status
GrpclbState. BALANCER_REQUESTED_FALLBACK_STATUS
(package private) static Status
GrpclbState. BALANCER_TIMEOUT_STATUS
private Status
GrpclbState. fallbackReason
(package private) static Status
GrpclbState. NO_AVAILABLE_BACKENDS_STATUS
(package private) static Status
GrpclbState. NO_FALLBACK_BACKENDS_STATUS
private static Status
GrpclbState. NO_LB_ADDRESS_PROVIDED_STATUS
private Status
GrpclbState.FallbackModeTask. reason
Methods in io.grpc.grpclb that return Status Modifier and Type Method Description Status
GrpclbLoadBalancer. acceptResolvedAddresses(LoadBalancer.ResolvedAddresses resolvedAddresses)
Methods in io.grpc.grpclb with parameters of type Status Modifier and Type Method Description void
GrpclbLoadBalancer. handleNameResolutionError(Status error)
private void
GrpclbState.LbStream. handleStreamClosed(Status error)
(package private) void
GrpclbState. propagateError(Status status)
void
GrpclbClientLoadRecorder.StreamTracer. streamClosed(Status status)
Constructors in io.grpc.grpclb with parameters of type Status Constructor Description ErrorEntry(Status status)
FallbackModeTask(Status reason)
-
Uses of Status in io.grpc.inprocess
Fields in io.grpc.inprocess declared as Status Modifier and Type Field Description private Status
InProcessTransport.InProcessStream.InProcessServerStream. clientNotifyStatus
private Status
InProcessTransport. shutdownStatus
Methods in io.grpc.inprocess that return Status Modifier and Type Method Description private static Status
InProcessTransport. cleanStatus(Status status, boolean includeCauseWithStatus)
Returns a new status with the same code and description.Methods in io.grpc.inprocess with parameters of type Status Modifier and Type Method Description void
InProcessTransport.InProcessStream.InProcessClientStream. cancel(Status reason)
void
InProcessTransport.InProcessStream.InProcessServerStream. cancel(Status status)
private static Status
InProcessTransport. cleanStatus(Status status, boolean includeCauseWithStatus)
Returns a new status with the same code and description.private void
InProcessTransport.InProcessStream.InProcessServerStream. clientCancelled(Status status)
void
InProcessTransport.InProcessStream.InProcessServerStream. close(Status status, Metadata trailers)
private ClientStream
InProcessTransport. failedClientStream(StatsTraceContext statsTraceCtx, Status status)
private boolean
InProcessTransport.InProcessStream.InProcessClientStream. internalCancel(Status serverListenerStatus, Status serverTracerStatus)
private boolean
InProcessTransport.InProcessStream.InProcessServerStream. internalCancel(Status clientStatus)
private void
InProcessTransport.InProcessStream.InProcessServerStream. notifyClientClose(Status status, Metadata trailers)
clientStream.serverClosed() must be called before this methodprivate void
InProcessTransport. notifyShutdown(Status s)
private void
InProcessTransport.InProcessStream.InProcessClientStream. serverClosed(Status serverListenerStatus, Status serverTracerStatus)
void
InProcessTransport. shutdown(Status reason)
void
InProcessTransport. shutdownNow(Status reason)
-
Uses of Status in io.grpc.internal
Fields in io.grpc.internal declared as Status Modifier and Type Field Description private Status
RetriableStream. cancellationStatus
private static Status
RetriableStream. CANCELLED_BECAUSE_COMMITTED
private Status
AbstractServerStream.TransportState. closedStatus
The status that the application used to close this stream.private Status
DelayedClientCall. error
private Status
DelayedStream. error
private Status
DnsNameResolver.InternalResolutionResult. error
private Status
FailingClientStream. error
(package private) Status
FailingClientTransport. error
private Status
ClientCallImpl.ClientStreamListenerImpl. exceptionStatus
private Status
AutoConfiguredLoadBalancerFactory.FailingPicker. failure
(package private) static Status
SubchannelChannel. NOT_READY_ERROR
private Status
CallCredentialsApplyingTransportFactory.CallCredentialsApplyingTransport. savedShutdownNowStatus
private Status
CallCredentialsApplyingTransportFactory.CallCredentialsApplyingTransport. savedShutdownStatus
(package private) static Status
ManagedChannelImpl. SHUTDOWN_NOW_STATUS
(package private) static Status
ManagedChannelImpl. SHUTDOWN_STATUS
private Status
ServerImpl. shutdownNowStatus
non-null
if immediate shutdown has been requested.private Status
InternalSubchannel. shutdownReason
private Status
CallCredentialsApplyingTransportFactory.CallCredentialsApplyingTransport. shutdownStatus
(package private) Status
DelayedClientTransport.PickerState. shutdownStatus
WhenshutdownStatus != null && !hasPendingStreams()
, then the transport is considered terminated.(package private) Status
ManagedChannelImpl.UncommittedRetriableStreamsRegistry. shutdownStatus
(package private) Status
DelayedClientCall.CloseListenerRunnable. status
private Status
GrpcUtil.Http2Error. status
private Status
RetriableStream.SavedCloseMasterListenerReason. status
(package private) static Status
ManagedChannelImpl. SUBCHANNEL_SHUTDOWN_STATUS
private Status
Http2ClientStreamTransportState. transportError
(package private) static Status
SubchannelChannel. WAIT_FOR_READY_ERROR
Methods in io.grpc.internal that return Status Modifier and Type Method Description Status
AutoConfiguredLoadBalancerFactory.NoopLoadBalancer. acceptResolvedAddresses(LoadBalancer.ResolvedAddresses resolvedAddresses)
Status
PickFirstLeafLoadBalancer. acceptResolvedAddresses(LoadBalancer.ResolvedAddresses resolvedAddresses)
Status
PickFirstLoadBalancer. acceptResolvedAddresses(LoadBalancer.ResolvedAddresses resolvedAddresses)
(package private) Status
ManagedChannelImpl.UncommittedRetriableStreamsRegistry. add(RetriableStream<?> retriableStream)
Registers a RetriableStream and return null if not shutdown, otherwise just returns the shutdown Status.(package private) Status
ClientCallImpl.CancellationHandler. formatDeadlineExceededStatus()
(package private) Status
FailingClientStream. getError()
static Status
GrpcUtil. httpStatusToGrpcStatus(int httpStatusCode)
Maps HTTP error response status codes to transport codes, as defined in http-grpc-status-mapping.md.Status
ManagedChannelImpl.NameResolverListener. onResult2(NameResolver.ResolutionResult resolutionResult)
Status
RetryingNameResolver.RetryingListener. onResult2(NameResolver.ResolutionResult resolutionResult)
(package private) abstract Status
RetriableStream. prestart()
Runs pre-start tasks.static Status
GrpcUtil. replaceInappropriateControlPlaneStatus(Status status)
Some status codes from the control plane are not appropritate to use in the data plane.Status
GrpcUtil.Http2Error. status()
Gets theStatus
associated with this HTTP/2 code.static Status
GrpcUtil.Http2Error. statusForCode(long code)
Looks up theStatus
from the given HTTP/2 error code.private Status
Http2ClientStreamTransportState. statusFromTrailers(Metadata trailers)
Extract the response status from trailers.(package private) Status
AutoConfiguredLoadBalancerFactory.AutoConfiguredLoadBalancer. tryAcceptResolvedAddresses(LoadBalancer.ResolvedAddresses resolvedAddresses)
Returns non-OK status if the delegate rejects the resolvedAddresses (e.g.private Status
Http2ClientStreamTransportState. validateInitialMetadata(Metadata headers)
Inspect initial headers to make sure they conform to HTTP and gRPC, returning aStatus
on failure.Methods in io.grpc.internal with parameters of type Status Modifier and Type Method Description private void
AbstractServerStream. addStatusToTrailers(Metadata trailers, Status status)
void
AbstractClientStream. cancel(Status reason)
void
AbstractClientStream.Sink. cancel(Status status)
Tears down the stream, typically in the event of a timeout.void
AbstractServerStream. cancel(Status status)
void
AbstractServerStream.Sink. cancel(Status status)
Tears down the stream, typically in the event of a timeout.void
ClientStream. cancel(Status reason)
Abnormally terminates the stream.private void
DelayedClientCall. cancel(Status status, boolean onlyCancelPendingCall)
Cancels the call unlessrealCall
is set andonlyCancelPendingCall
is true.void
DelayedClientTransport.PendingStream. cancel(Status reason)
void
DelayedStream. cancel(Status reason)
void
ForwardingClientStream. cancel(Status reason)
void
NoopClientStream. cancel(Status status)
void
RetriableStream. cancel(Status reason)
void
ServerStream. cancel(Status status)
Tears down the stream, typically in the event of a timeout.void
AbstractServerStream. close(Status status, Metadata trailers)
void
ServerCallImpl. close(Status status, Metadata trailers)
void
ServerStream. close(Status status, Metadata trailers)
Closes the stream for both reading and writing.void
ClientCallImpl.ClientStreamListenerImpl. closed(Status status, ClientStreamListener.RpcProgress rpcProgress, Metadata trailers)
void
ClientStreamListener. closed(Status status, ClientStreamListener.RpcProgress rpcProgress, Metadata trailers)
Called when the stream is fully closed.void
DelayedStream.DelayedStreamListener. closed(Status status, ClientStreamListener.RpcProgress rpcProgress, Metadata trailers)
void
ForwardingClientStreamListener. closed(Status status, ClientStreamListener.RpcProgress rpcProgress, Metadata trailers)
void
RetriableStream.Sublistener. closed(Status status, ClientStreamListener.RpcProgress rpcProgress, Metadata trailers)
void
ServerCallImpl.ServerStreamListenerImpl. closed(Status status)
void
ServerImpl.JumpToApplicationThreadServerStreamListener. closed(Status status)
void
ServerImpl.NoopListener. closed(Status status)
void
ServerStreamListener. closed(Status status)
Called when the stream is fully closed.private void
ClientCallImpl.ClientStreamListenerImpl. closedInternal(Status status, ClientStreamListener.RpcProgress rpcProgress, Metadata trailers)
private void
ServerCallImpl.ServerStreamListenerImpl. closedInternal(Status status)
private void
ServerImpl.JumpToApplicationThreadServerStreamListener. closedInternal(Status status)
private void
ServerCallImpl. closeInternal(Status status, Metadata trailers)
private void
AbstractClientStream.TransportState. closeListener(Status status, ClientStreamListener.RpcProgress rpcProgress, Metadata trailers)
Closes the listener if not previously closed.private void
AbstractServerStream.TransportState. closeListener(Status newStatus)
Closes the listener if not previously closed and frees resources.private void
ClientCallImpl. closeObserver(ClientCall.Listener<RespT> observer, Status status, Metadata trailers)
private void
ClientCallImpl.ClientStreamListenerImpl. exceptionThrown(Status status)
Cancels call and schedules onClose() notification.private void
ManagedChannelImpl.ConfigSelectingClientCall. executeCloseObserverInContext(ClientCall.Listener<RespT> observer, Status status)
void
MetadataApplierImpl. fail(Status status)
private void
ManagedChannelImpl.NameResolverListener. handleErrorInSyncContext(Status error)
(package private) void
AutoConfiguredLoadBalancerFactory.AutoConfiguredLoadBalancer. handleNameResolutionError(Status error)
void
AutoConfiguredLoadBalancerFactory.NoopLoadBalancer. handleNameResolutionError(Status error)
void
PickFirstLeafLoadBalancer. handleNameResolutionError(Status error)
void
PickFirstLoadBalancer. handleNameResolutionError(Status error)
protected abstract void
Http2ClientStreamTransportState. http2ProcessingFailed(Status status, boolean stopDelivery, Metadata trailers)
Called to process a failure in HTTP/2 processing.protected void
AbstractClientStream.TransportState. inboundTrailersReceived(Metadata trailers, Status status)
Processes the trailers and status from the server.private RetriableStream.HedgingPlan
RetriableStream.Sublistener. makeHedgingDecision(Status status, Metadata trailer)
private RetriableStream.RetryPlan
RetriableStream.Sublistener. makeRetryDecision(Status status, Metadata trailer)
Decides in current situation whether or not the RPC should retry and if it should retry how long the backoff should be.void
DelayedClientCall.DelayedListener. onClose(Status status, Metadata trailers)
protected void
DelayedClientTransport.PendingStream. onEarlyCancellation(Status reason)
protected void
DelayedStream. onEarlyCancellation(Status reason)
void
ManagedChannelImpl.NameResolverListener. onError(Status error)
void
RetryingNameResolver.RetryingListener. onError(Status error)
(package private) void
ManagedChannelImpl.UncommittedRetriableStreamsRegistry. onShutdown(Status reason)
(package private) void
ManagedChannelImpl.UncommittedRetriableStreamsRegistry. onShutdownNow(Status reason)
private java.lang.String
InternalSubchannel. printShortStatus(Status status)
static Status
GrpcUtil. replaceInappropriateControlPlaneStatus(Status status)
Some status codes from the control plane are not appropritate to use in the data plane.void
RetryingNameResolver.ResolutionResultListener. resolutionAttempted(Status successStatus)
private void
RetriableStream. safeCloseMasterListener(Status status, ClientStreamListener.RpcProgress progress, Metadata metadata)
private void
InternalSubchannel. scheduleBackoff(Status status)
Only called after all addresses attempted and failed (TRANSIENT_FAILURE).private void
AbstractServerStream.TransportState. setClosedStatus(Status closeStatus)
Stores theStatus
that the application used to close this stream.void
CallCredentialsApplyingTransportFactory.CallCredentialsApplyingTransport. shutdown(Status status)
void
DelayedClientTransport. shutdown(Status status)
Prevents creating any new streams.void
ForwardingConnectionClientTransport. shutdown(Status status)
void
InternalSubchannel. shutdown(Status reason)
void
ManagedClientTransport. shutdown(Status reason)
Initiates an orderly shutdown of the transport.void
CallCredentialsApplyingTransportFactory.CallCredentialsApplyingTransport. shutdownNow(Status status)
void
DelayedClientTransport. shutdownNow(Status status)
Shuts down this transport and cancels all streams that it owns, hence immediately terminates this transport.void
ForwardingConnectionClientTransport. shutdownNow(Status status)
(package private) void
InternalSubchannel. shutdownNow(Status reason)
void
ManagedClientTransport. shutdownNow(Status reason)
Initiates a forceful shutdown in which preexisting and new calls are closed.void
ServerTransport. shutdownNow(Status reason)
Initiates a forceful shutdown in which preexisting and new calls are closed.void
ForwardingClientStreamTracer. streamClosed(Status status)
void
StatsTraceContext. streamClosed(Status status)
void
AbstractClientStream.TransportState. transportReportStatus(Status status, boolean stopDelivery, Metadata trailers)
Report stream closure with status to the application layer if not already reported.void
AbstractClientStream.TransportState. transportReportStatus(Status status, ClientStreamListener.RpcProgress rpcProgress, boolean stopDelivery, Metadata trailers)
Report stream closure with status to the application layer if not already reported.void
AbstractServerStream.TransportState. transportReportStatus(Status status)
Notifies failure to the listener of the stream.void
InternalSubchannel.TransportListener. transportShutdown(Status s)
void
ManagedChannelImpl.DelayedTransportListener. transportShutdown(Status s)
void
ManagedClientTransport.Listener. transportShutdown(Status s)
The transport is shutting down.DelayedClientTransport.PickerState
DelayedClientTransport.PickerState. withShutdownStatus(Status newShutdownStatus)
void
AbstractServerStream.Sink. writeTrailers(Metadata trailers, boolean headersSent, Status status)
Sends trailers to the remote end point.Constructors in io.grpc.internal with parameters of type Status Constructor Description CloseListenerRunnable(ClientCall.Listener<RespT> listener, Status status)
FailingClientStream(Status error, ClientStreamTracer[] tracers)
Creates aFailingClientStream
that would fail with the given error.FailingClientStream(Status error, ClientStreamListener.RpcProgress rpcProgress, ClientStreamTracer[] tracers)
Creates aFailingClientStream
that would fail with the given error.FailingClientTransport(Status error, ClientStreamListener.RpcProgress rpcProgress)
FailingPicker(Status failure)
Http2Error(int code, Status status)
PickerState(LoadBalancer.SubchannelPicker lastPicker, Status shutdownStatus)
SavedCloseMasterListenerReason(Status status, ClientStreamListener.RpcProgress progress, Metadata metadata)
-
Uses of Status in io.grpc.netty
Fields in io.grpc.netty declared as Status Modifier and Type Field Description private Status
NettyClientHandler. abruptGoAwayStatus
private Status
NettyClientHandler. channelInactiveReason
private static Status
NettyClientHandler. EXHAUSTED_STREAMS_STATUS
Status used when the transport has exhausted the number of streams.private Status
CancelClientStreamCommand. reason
private Status
CancelServerStreamCommand. reason
private Status
ClientTransportLifecycleManager. shutdownStatus
null iff !transportShutdown.private Status
ForcefulCloseCommand. status
private Status
GracefulCloseCommand. status
private Status
SendResponseHeadersCommand. status
private Status
NettyClientTransport. statusExplainingWhyTheChannelIsNull
IfNettyClientTransport.start(io.grpc.internal.ManagedClientTransport.Listener)
has been called, non-null
if channel isnull
.Methods in io.grpc.netty that return Status Modifier and Type Method Description Status
ClientTransportLifecycleManager. getShutdownStatus()
Status
ForcefulCloseCommand. getStatus()
Status
GracefulCloseCommand. getStatus()
(package private) Status
CancelClientStreamCommand. reason()
(package private) Status
CancelServerStreamCommand. reason()
(package private) Status
SendResponseHeadersCommand. status()
protected abstract Status
NettyClientStream.TransportState. statusFromFailedFuture(io.netty.channel.ChannelFuture f)
Intended to be overridden by NettyClientTransport, which has more information about failures.private Status
NettyClientTransport. statusFromFailedFuture(io.netty.channel.ChannelFuture f)
Convert ChannelFuture.cause() to a Status, taking into account that all handlers are removed from the pipeline when the channel is closed.private Status
NettyClientHandler. statusFromH2Error(Status.Code statusCode, java.lang.String context, long errorCode, byte[] debugData)
IfstatusCode
is non-null, it will be used instead of the http2 error code mapping.static Status
Utils. statusFromThrowable(java.lang.Throwable t)
Methods in io.grpc.netty with parameters of type Status Modifier and Type Method Description void
NettyClientStream.Sink. cancel(Status status)
void
NettyServerStream.Sink. cancel(Status status)
(package private) static SendResponseHeadersCommand
SendResponseHeadersCommand. createTrailers(StreamIdHolder stream, io.netty.handler.codec.http2.Http2Headers headers, Status status)
protected void
NettyClientStream.TransportState. http2ProcessingFailed(Status status, boolean stopDelivery, Metadata trailers)
protected void
NettyServerStream.TransportState. http2ProcessingFailed(Status status)
Called to process a failure in HTTP/2 processing.void
ClientTransportLifecycleManager. notifyGracefulShutdown(Status s)
Marks transport as shutdown, but does not set the error status.boolean
ClientTransportLifecycleManager. notifyShutdown(Status s)
Returnstrue
if was the first shutdown.void
ClientTransportLifecycleManager. notifyTerminated(Status s)
void
NettyClientTransport. shutdown(Status reason)
void
NettyClientTransport. shutdownNow(Status reason)
void
NettyServerTransport. shutdownNow(Status reason)
(package private) static CancelServerStreamCommand
CancelServerStreamCommand. withReason(NettyServerStream.TransportState stream, Status reason)
(package private) static CancelServerStreamCommand
CancelServerStreamCommand. withReset(NettyServerStream.TransportState stream, Status reason)
void
NettyServerStream.Sink. writeTrailers(Metadata trailers, boolean headersSent, Status status)
Constructors in io.grpc.netty with parameters of type Status Constructor Description CancelClientStreamCommand(NettyClientStream.TransportState stream, Status reason)
CancelServerStreamCommand(NettyServerStream.TransportState stream, Status reason, CancelServerStreamCommand.PeerNotify peerNotify)
ForcefulCloseCommand(Status status)
GracefulCloseCommand(Status status)
SendResponseHeadersCommand(StreamIdHolder stream, io.netty.handler.codec.http2.Http2Headers headers, Status status)
-
Uses of Status in io.grpc.protobuf
Methods in io.grpc.protobuf that return Status Modifier and Type Method Description private static Status
StatusProto. toStatus(com.google.rpc.Status statusProto)
Methods in io.grpc.protobuf with parameters of type Status Modifier and Type Method Description static com.google.rpc.Status
StatusProto. fromStatusAndTrailers(Status status, Metadata trailers)
Extracts thegoogle.rpc.Status
from trailers, and makes sure they match the gRPCstatus
. -
Uses of Status in io.grpc.protobuf.services
Methods in io.grpc.protobuf.services with parameters of type Status Modifier and Type Method Description (package private) void
HealthCheckingLoadBalancerFactory.HealthCheckState.HcStream. handleStreamClosed(Status status)
(package private) abstract void
BinlogHelper.SinkWriter. logTrailer(long seq, Status status, Metadata metadata, GrpcLogEntry.Logger logger, long callId, java.net.SocketAddress peerAddress)
Logs the server trailer.(package private) void
BinlogHelper.SinkWriterImpl. logTrailer(long seq, Status status, Metadata metadata, GrpcLogEntry.Logger logger, long callId, java.net.SocketAddress peerAddress)
void
HealthCheckingLoadBalancerFactory.HealthCheckState.HcStream. onClose(Status status, Metadata trailers)
-
Uses of Status in io.grpc.rls
Fields in io.grpc.rls declared as Status Modifier and Type Field Description private Status
CachingRlsLbClient.BackoffCacheEntry. status
Methods in io.grpc.rls that return Status Modifier and Type Method Description Status
RlsLoadBalancer. acceptResolvedAddresses(LoadBalancer.ResolvedAddresses resolvedAddresses)
(package private) static Status
CachingRlsLbClient. convertRlsServerStatus(Status status, java.lang.String serverName)
Convert the status to UNAVAILABLE and enhance the error message.(package private) Status
CachingRlsLbClient.BackoffCacheEntry. getStatus()
(package private) Status
CachingRlsLbClient.CachedRouteLookupResponse. getStatus()
Methods in io.grpc.rls with parameters of type Status Modifier and Type Method Description (package private) static Status
CachingRlsLbClient. convertRlsServerStatus(Status status, java.lang.String serverName)
Convert the status to UNAVAILABLE and enhance the error message.private CachingRlsLbClient.BackoffCacheEntry
CachingRlsLbClient. createBackOffEntry(RlsProtoData.RouteLookupRequest request, Status status, BackoffPolicy backoffPolicy)
void
RlsLoadBalancer. handleNameResolutionError(Status error)
Constructors in io.grpc.rls with parameters of type Status Constructor Description BackoffCacheEntry(RlsProtoData.RouteLookupRequest request, Status status, BackoffPolicy backoffPolicy)
-
Uses of Status in io.grpc.servlet
Methods in io.grpc.servlet with parameters of type Status Modifier and Type Method Description void
ServletServerStream.Sink. cancel(Status status)
void
ServletServerBuilder.ServerTransportImpl. shutdownNow(Status reason)
void
ServletServerStream.Sink. writeTrailers(Metadata trailers, boolean headersSent, Status status)
-
Uses of Status in io.grpc.servlet.jakarta
Methods in io.grpc.servlet.jakarta with parameters of type Status Modifier and Type Method Description void
ServletServerStream.Sink. cancel(Status status)
void
ServletServerBuilder.ServerTransportImpl. shutdownNow(Status reason)
void
ServletServerStream.Sink. writeTrailers(Metadata trailers, boolean headersSent, Status status)
-
Uses of Status in io.grpc.stub
Methods in io.grpc.stub with parameters of type Status Modifier and Type Method Description void
MetadataUtils.MetadataAttachingServerInterceptor.MetadataAttachingServerCall. close(Status status, Metadata trailers)
void
ClientCalls.BlockingResponseStream.QueuingListener. onClose(Status status, Metadata trailers)
void
ClientCalls.StreamObserverToCallListenerAdapter. onClose(Status status, Metadata trailers)
void
ClientCalls.UnaryStreamToFuture. onClose(Status status, Metadata trailers)
void
MetadataUtils.MetadataCapturingClientInterceptor.MetadataCapturingClientCall.MetadataCapturingClientCallListener. onClose(Status status, Metadata trailers)
-
Uses of Status in io.grpc.util
Fields in io.grpc.util declared as Status Modifier and Type Field Description Status
MultiChildLoadBalancer.AcceptResolvedAddrRetVal. status
Methods in io.grpc.util that return Status Modifier and Type Method Description Status
GracefulSwitchLoadBalancer. acceptResolvedAddresses(LoadBalancer.ResolvedAddresses resolvedAddresses)
Status
MultiChildLoadBalancer. acceptResolvedAddresses(LoadBalancer.ResolvedAddresses resolvedAddresses)
Override to completely replace the default logic or to do additional activities.Status
OutlierDetectionLoadBalancer. acceptResolvedAddresses(LoadBalancer.ResolvedAddresses resolvedAddresses)
Methods in io.grpc.util with parameters of type Status Modifier and Type Method Description void
TransmitStatusRuntimeExceptionInterceptor.SerializingServerCall. close(Status status, Metadata trailers)
void
ForwardingLoadBalancer. handleNameResolutionError(Status error)
void
MultiChildLoadBalancer. handleNameResolutionError(Status error)
Handle the name resolution error.void
OutlierDetectionLoadBalancer. handleNameResolutionError(Status error)
void
ForwardingClientStreamTracer. streamClosed(Status status)
Constructors in io.grpc.util with parameters of type Status Constructor Description AcceptResolvedAddrRetVal(Status status, java.util.List<MultiChildLoadBalancer.ChildLbState> removedChildren)
-