A B C D E F G H I L M N O P Q R S T U V W
All Classes All Packages
All Classes All Packages
All Classes All Packages
A
- ABORTED - com.google.api.gax.rpc.StatusCode.Code
- AbortedException - Exception in com.google.api.gax.rpc
-
Exception thrown when the operation was aborted, typically due to a concurrency issue like sequencer check failures, transaction aborts, etc.
- AbortedException(String, Throwable, StatusCode, boolean) - Constructor for exception com.google.api.gax.rpc.AbortedException
- AbortedException(Throwable, StatusCode, boolean) - Constructor for exception com.google.api.gax.rpc.AbortedException
- AbortedException(Throwable, StatusCode, boolean, ErrorDetails) - Constructor for exception com.google.api.gax.rpc.AbortedException
- AbstractFixedSizeCollection<RequestT,ResponseT,ResourceT,PageT extends AbstractPage<RequestT,ResponseT,ResourceT,PageT>,CollectionT extends AbstractFixedSizeCollection<RequestT,ResponseT,ResourceT,PageT,CollectionT>> - Class in com.google.api.gax.paging
-
Partial implementation of
FixedSizeCollection
. - AbstractFixedSizeCollection(List<PageT>, int) - Constructor for class com.google.api.gax.paging.AbstractFixedSizeCollection
- AbstractPage<RequestT,ResponseT,ResourceT,PageT extends AbstractPage<RequestT,ResponseT,ResourceT,PageT>> - Class in com.google.api.gax.paging
-
Partial implementation of
AsyncPage
. - AbstractPage(PageContext<RequestT, ResponseT, ResourceT>, ResponseT) - Constructor for class com.google.api.gax.paging.AbstractPage
- AbstractPagedListResponse<RequestT,ResponseT,ResourceT,PageT extends AbstractPage<RequestT,ResponseT,ResourceT,PageT>,CollectionT extends AbstractFixedSizeCollection<RequestT,ResponseT,ResourceT,PageT,CollectionT>> - Class in com.google.api.gax.paging
-
Partial implementation of
PagedListResponse
. - AbstractPagedListResponse(PageT, CollectionT) - Constructor for class com.google.api.gax.paging.AbstractPagedListResponse
- acceptsPoolSize() - Method in class com.google.api.gax.grpc.InstantiatingGrpcChannelProvider
-
Deprecated.Please modify pool settings via
InstantiatingGrpcChannelProvider.toBuilder()
- acceptsPoolSize() - Method in class com.google.api.gax.httpjson.InstantiatingHttpJsonChannelProvider
-
Deprecated.REST transport channel doesn't support channel pooling
- acceptsPoolSize() - Method in class com.google.api.gax.rpc.FixedTransportChannelProvider
-
Deprecated.FixedTransportChannelProvider doesn't support ChannelPool configuration
- acceptsPoolSize() - Method in interface com.google.api.gax.rpc.TransportChannelProvider
-
Deprecated.Pool settings should be configured on the builder of the specific implementation.
- accumulate(E) - Method in interface com.google.api.gax.batching.BatchingThreshold
-
Presents the element to the threshold for the attribute of interest to be accumulated.
- accumulate(E) - Method in class com.google.api.gax.batching.NumericThreshold
- AccumulatingBatchReceiver<T> - Class in com.google.api.gax.batching
-
A simple ThresholdBatchReceiver that just accumulates batches.
- AccumulatingBatchReceiver(ApiFuture<?>) - Constructor for class com.google.api.gax.batching.AccumulatingBatchReceiver
- add(E) - Method in class com.google.api.gax.batching.ThresholdBatcher
-
Adds an element to the batcher.
- add(ElementT) - Method in interface com.google.api.gax.batching.Batcher
-
Queues the passed in element to be sent at some point in the future.
- add(ElementT) - Method in class com.google.api.gax.batching.BatcherImpl
-
Queues the passed in element to be sent at some point in the future.
- add(ElementT) - Method in interface com.google.api.gax.batching.BatchingRequestBuilder
-
Adds element object into client specific batch request.
- add(String, String, PathTemplate) - Method in class com.google.api.gax.rpc.RequestParamsBuilder
-
Add an entry to paramsBuilder by match-and-extract field values from requests based on pre-configured path templates.
- addHandlers(ApiCallContext) - Method in class com.google.api.gax.grpc.GrpcResponseMetadata
-
Constructs a new call context from an existing ApiCallContext, and sets the CallOptions to add handlers to retrieve the headers and trailers, and make them available via the getMetadata and getTrailingMetadata methods.
- addListener(Runnable, Executor) - Method in class com.google.api.gax.longrunning.OperationFutureImpl
- all() - Method in class com.google.api.gax.rpc.ServerStreamingCallable
-
Construct a
UnaryCallable
that will buffer the entire stream into memory before completing. - ALREADY_EXISTS - com.google.api.gax.rpc.StatusCode.Code
- AlreadyExistsException - Exception in com.google.api.gax.rpc
-
Exception thrown when some entity that we attempted to create (e.g., file or directory) already exists.
- AlreadyExistsException(String, Throwable, StatusCode, boolean) - Constructor for exception com.google.api.gax.rpc.AlreadyExistsException
- AlreadyExistsException(Throwable, StatusCode, boolean) - Constructor for exception com.google.api.gax.rpc.AlreadyExistsException
- AlreadyExistsException(Throwable, StatusCode, boolean, ErrorDetails) - Constructor for exception com.google.api.gax.rpc.AlreadyExistsException
- ALWAYS - com.google.api.gax.rpc.mtls.MtlsProvider.MtlsEndpointUsagePolicy
- ApiCallContext - Interface in com.google.api.gax.rpc
-
Context for an API call.
- ApiCallContext.Key<T> - Class in com.google.api.gax.rpc
-
Key for api call context options key-value pair.
- ApiCallContextOptions - Class in com.google.api.gax.rpc.internal
-
ApiCallContextOptions encapsulates additional call options to pass in a
ApiCallContext
- ApiClientHeaderProvider - Class in com.google.api.gax.rpc
-
Implementation of HeaderProvider that provides headers describing the API client library making API calls.
- ApiClientHeaderProvider(ApiClientHeaderProvider.Builder) - Constructor for class com.google.api.gax.rpc.ApiClientHeaderProvider
- ApiClientHeaderProvider.Builder - Class in com.google.api.gax.rpc
- ApiException - Exception in com.google.api.gax.rpc
-
Represents an exception thrown during an RPC call.
- ApiException(String, Throwable, StatusCode, boolean) - Constructor for exception com.google.api.gax.rpc.ApiException
- ApiException(Throwable, StatusCode, boolean) - Constructor for exception com.google.api.gax.rpc.ApiException
- ApiException(Throwable, StatusCode, boolean, ErrorDetails) - Constructor for exception com.google.api.gax.rpc.ApiException
- ApiExceptionFactory - Class in com.google.api.gax.rpc
-
A factory class that returns the corresponding type of exception class from the given status code.
- ApiExceptions - Class in com.google.api.gax.rpc
-
A utility class for working with
ApiException
. - ApiMethodDescriptor<RequestT,ResponseT> - Class in com.google.api.gax.httpjson
- ApiMethodDescriptor() - Constructor for class com.google.api.gax.httpjson.ApiMethodDescriptor
- ApiMethodDescriptor.Builder<RequestT,ResponseT> - Class in com.google.api.gax.httpjson
- ApiMethodDescriptor.MethodType - Enum in com.google.api.gax.httpjson
- ApiStreamObserver<V> - Interface in com.google.api.gax.rpc
-
Receives notifications from an observable stream of messages.
- ApiTracer - Interface in com.google.api.gax.tracing
-
Implementations of this class trace the logical flow of a google cloud client.
- ApiTracer.Scope - Interface in com.google.api.gax.tracing
-
A context class to be used with
ApiTracer.inScope()
and a try-with-resources block. - ApiTracerFactory - Interface in com.google.api.gax.tracing
-
A factory to create new instances of
ApiTracer
s. - ApiTracerFactory.OperationType - Enum in com.google.api.gax.tracing
-
The type of operation the
ApiTracer
is tracing. - appendRequest(RequestT) - Method in interface com.google.api.gax.batching.RequestBuilder
- appendToken(StringBuilder, String) - Static method in class com.google.api.gax.rpc.ApiClientHeaderProvider
- apply(OperationSnapshot) - Method in class com.google.api.gax.grpc.ProtoOperationTransformers.MetadataTransformer
- apply(OperationSnapshot) - Method in class com.google.api.gax.grpc.ProtoOperationTransformers.ResponseTransformer
- apply(OperationSnapshot) - Method in class com.google.api.gax.httpjson.ProtoOperationTransformers.MetadataTransformer
- apply(OperationSnapshot) - Method in class com.google.api.gax.httpjson.ProtoOperationTransformers.ResponseTransformer
- applyToAllUnaryMethods(ApiFunction<UnaryCallSettings.Builder<?, ?>, Void>) - Method in class com.google.api.gax.httpjson.longrunning.OperationsSettings.Builder
-
Applies the given settings updater function to all of the unary API methods in this service.
- applyToAllUnaryMethods(ApiFunction<UnaryCallSettings.Builder<?, ?>, Void>) - Method in class com.google.api.gax.httpjson.longrunning.stub.OperationsStubSettings.Builder
-
Applies the given settings updater function to all of the unary API methods in this service.
- applyToAllUnaryMethods(ApiFunction<UnaryCallSettings.Builder<?, ?>, Void>) - Method in class com.google.longrunning.OperationsSettings.Builder
-
Applies the given settings updater function to all of the unary API methods in this service.
- applyToAllUnaryMethods(ApiFunction<UnaryCallSettings.Builder<?, ?>, Void>) - Method in class com.google.longrunning.stub.OperationsStubSettings.Builder
-
Applies the given settings updater function to all of the unary API methods in this service.
- applyToAllUnaryMethods(Iterable<UnaryCallSettings.Builder<?, ?>>, ApiFunction<UnaryCallSettings.Builder<?, ?>, Void>) - Static method in class com.google.api.gax.rpc.ClientSettings.Builder
-
Applies the given settings updater function to the given method settings builders.
- applyToAllUnaryMethods(Iterable<UnaryCallSettings.Builder<?, ?>>, ApiFunction<UnaryCallSettings.Builder<?, ?>, Void>) - Static method in class com.google.api.gax.rpc.StubSettings.Builder
-
Applies the given settings updater function to the given method settings builders.
- AsyncPage<ResourceT> - Interface in com.google.api.gax.paging
-
An AsyncPage extends a
Page
object with a getNextPageAsync method. - AsyncTaskException - Exception in com.google.api.gax.rpc
-
This exception is used to preserve the caller's stacktrace when invoking an async task in a sync context.
- attemptCancelled() - Method in interface com.google.api.gax.tracing.ApiTracer
-
Add an annotation that the attempt was cancelled by the user.
- attemptCancelled() - Method in class com.google.api.gax.tracing.BaseApiTracer
- attemptCancelled() - Method in class com.google.api.gax.tracing.OpencensusTracer
-
Add an annotation that the attempt was cancelled by the user.
- attemptFailed(Throwable, Duration) - Method in interface com.google.api.gax.tracing.ApiTracer
-
Adds an annotation that the attempt failed, but another attempt will be made after the delay.
- attemptFailed(Throwable, Duration) - Method in class com.google.api.gax.tracing.BaseApiTracer
- attemptFailed(Throwable, Duration) - Method in class com.google.api.gax.tracing.OpencensusTracer
-
Adds an annotation that the attempt failed, but another attempt will be made after the delay.
- attemptFailedRetriesExhausted(Throwable) - Method in interface com.google.api.gax.tracing.ApiTracer
-
Adds an annotation that the attempt failed and that no further attempts will be made because retry limits have been reached.
- attemptFailedRetriesExhausted(Throwable) - Method in class com.google.api.gax.tracing.BaseApiTracer
- attemptFailedRetriesExhausted(Throwable) - Method in class com.google.api.gax.tracing.OpencensusTracer
-
Adds an annotation that the attempt failed and that no further attempts will be made because retry limits have been reached.
- attemptPermanentFailure(Throwable) - Method in interface com.google.api.gax.tracing.ApiTracer
-
Adds an annotation that the attempt failed and that no further attempts will be made because the last error was not retryable.
- attemptPermanentFailure(Throwable) - Method in class com.google.api.gax.tracing.BaseApiTracer
- attemptPermanentFailure(Throwable) - Method in class com.google.api.gax.tracing.OpencensusTracer
-
Adds an annotation that the attempt failed and that no further attempts will be made because the last error was not retryable.
- attemptStarted(int) - Method in interface com.google.api.gax.tracing.ApiTracer
-
Deprecated.Please use
ApiTracer.attemptStarted(Object, int)
instead. - attemptStarted(int) - Method in class com.google.api.gax.tracing.BaseApiTracer
- attemptStarted(int) - Method in class com.google.api.gax.tracing.OpencensusTracer
-
Adds an annotation that an attempt is about to start.
- attemptStarted(Object, int) - Method in interface com.google.api.gax.tracing.ApiTracer
-
Adds an annotation that an attempt is about to start with additional information from the request.
- attemptStarted(Object, int) - Method in class com.google.api.gax.tracing.BaseApiTracer
- attemptStarted(Object, int) - Method in class com.google.api.gax.tracing.OpencensusTracer
-
Adds an annotation that an attempt is about to start with additional information from the request.
- attemptSucceeded() - Method in interface com.google.api.gax.tracing.ApiTracer
-
Adds an annotation that the attempt succeeded.
- attemptSucceeded() - Method in class com.google.api.gax.tracing.BaseApiTracer
- attemptSucceeded() - Method in class com.google.api.gax.tracing.OpencensusTracer
-
Adds an annotation that the attempt succeeded.
- AUTO - com.google.api.gax.rpc.mtls.MtlsProvider.MtlsEndpointUsagePolicy
- awaitTermination(long, TimeUnit) - Method in interface com.google.api.gax.core.BackgroundResource
-
Blocks until all work has completed execution after a shutdown request, or the timeout occurs, or the current thread is interrupted, whichever happens first.
- awaitTermination(long, TimeUnit) - Method in class com.google.api.gax.core.BackgroundResourceAggregation
- awaitTermination(long, TimeUnit) - Method in class com.google.api.gax.core.BaseBackgroundResource
- awaitTermination(long, TimeUnit) - Method in class com.google.api.gax.core.ExecutorAsBackgroundResource
- awaitTermination(long, TimeUnit) - Method in class com.google.api.gax.grpc.GrpcTransportChannel
- awaitTermination(long, TimeUnit) - Method in class com.google.api.gax.httpjson.HttpJsonTransportChannel
- awaitTermination(long, TimeUnit) - Method in class com.google.api.gax.httpjson.longrunning.OperationsClient
- awaitTermination(long, TimeUnit) - Method in class com.google.api.gax.httpjson.longrunning.stub.HttpJsonOperationsStub
- awaitTermination(long, TimeUnit) - Method in class com.google.api.gax.httpjson.ManagedHttpJsonChannel
- awaitTermination(long, TimeUnit) - Method in class com.google.api.gax.rpc.Watchdog
- awaitTermination(long, TimeUnit) - Method in class com.google.longrunning.OperationsClient
- awaitTermination(long, TimeUnit) - Method in class com.google.longrunning.stub.GrpcOperationsStub
B
- BackgroundResource - Interface in com.google.api.gax.core
-
Represents a resource running in the background that needs to be shut down for resources to be released.
- BackgroundResourceAggregation - Class in com.google.api.gax.core
-
Treats a collection of background resources as a single background resource.
- BackgroundResourceAggregation(List<BackgroundResource>) - Constructor for class com.google.api.gax.core.BackgroundResourceAggregation
- BaseApiTracer - Class in com.google.api.gax.tracing
-
A base implementation of
ApiTracer
that does nothing. - BaseApiTracer() - Constructor for class com.google.api.gax.tracing.BaseApiTracer
- BaseApiTracerFactory - Class in com.google.api.gax.tracing
-
Base factory that will build
ApiTracer
s that do nothing. - BaseApiTracerFactory() - Constructor for class com.google.api.gax.tracing.BaseApiTracerFactory
- BaseBackgroundResource - Class in com.google.api.gax.core
-
A Background resource that does nothing.
- BaseBackgroundResource() - Constructor for class com.google.api.gax.core.BaseBackgroundResource
- BasicResultRetryAlgorithm<ResponseT> - Class in com.google.api.gax.retrying
-
A basic implementation of
ResultRetryAlgorithm
. - BasicResultRetryAlgorithm() - Constructor for class com.google.api.gax.retrying.BasicResultRetryAlgorithm
- Batch<RequestT,ResponseT> - Class in com.google.api.gax.rpc
-
A Batch contains a collection of requests that are to be batched into a single API call.
- Batch(BatchingDescriptor<RequestT, ResponseT>, RequestT, UnaryCallable<RequestT, ResponseT>, BatchedFuture<ResponseT>) - Constructor for class com.google.api.gax.rpc.Batch
- BatchedFuture<ResponseT> - Class in com.google.api.gax.rpc
-
An ApiFuture to be used with batching.
- BatchedFuture() - Constructor for class com.google.api.gax.rpc.BatchedFuture
- BatchedRequestIssuer<ResponseT> - Class in com.google.api.gax.rpc
-
BatchedRequestIssuer receives a response or an exception and waits to set the given batchedFuture until sendResult() is called.
- BatchedRequestIssuer(BatchedFuture<ResponseT>, long) - Constructor for class com.google.api.gax.rpc.BatchedRequestIssuer
- BatchEntry<ElementT,ElementResultT> - Class in com.google.api.gax.batching
-
This class contains the element and its corresponding unresolved future, which would be resolved when batch is
successful
orfailed
. - BatchEntry() - Constructor for class com.google.api.gax.batching.BatchEntry
- Batcher<ElementT,ElementResultT> - Interface in com.google.api.gax.batching
-
Represents a batching context where individual elements will be accumulated and flushed in a large batch request at some point in the future.
- BatcherFactory<RequestT,ResponseT> - Class in com.google.api.gax.rpc
-
A Factory class which, for each unique partitionKey, creates a trio including a ThresholdBatcher, BatchExecutor, and ThresholdBatchingForwarder.
- BatcherFactory(BatchingDescriptor<RequestT, ResponseT>, BatchingSettings, ScheduledExecutorService, FlowController) - Constructor for class com.google.api.gax.rpc.BatcherFactory
- BatcherImpl<ElementT,ElementResultT,RequestT,ResponseT> - Class in com.google.api.gax.batching
-
Queues up the elements until
BatcherImpl.flush()
is called; once batching is over, returned future resolves. - BatcherImpl(BatchingDescriptor<ElementT, ElementResultT, RequestT, ResponseT>, UnaryCallable<RequestT, ResponseT>, RequestT, BatchingSettings, ScheduledExecutorService) - Constructor for class com.google.api.gax.batching.BatcherImpl
-
Deprecated.Please instantiate the Batcher with
FlowController
andApiCallContext
- BatcherImpl(BatchingDescriptor<ElementT, ElementResultT, RequestT, ResponseT>, UnaryCallable<RequestT, ResponseT>, RequestT, BatchingSettings, ScheduledExecutorService, FlowController) - Constructor for class com.google.api.gax.batching.BatcherImpl
-
Deprecated.Please instantiate the Batcher with
ApiCallContext
- BatcherImpl(BatchingDescriptor<ElementT, ElementResultT, RequestT, ResponseT>, UnaryCallable<RequestT, ResponseT>, RequestT, BatchingSettings, ScheduledExecutorService, FlowController, ApiCallContext) - Constructor for class com.google.api.gax.batching.BatcherImpl
- batching(UnaryCallable<RequestT, ResponseT>, BatchingCallSettings<RequestT, ResponseT>, ClientContext) - Static method in class com.google.api.gax.rpc.Callables
-
Create a callable object that represents a batching API method.
- Batching - com.google.api.gax.tracing.ApiTracerFactory.OperationType
- BatchingCallable<RequestT,ResponseT> - Class in com.google.api.gax.rpc
-
A
UnaryCallable
which will batch requests based on the given BatchingDescriptor and BatcherFactory. - BatchingCallable(UnaryCallable<RequestT, ResponseT>, BatchingDescriptor<RequestT, ResponseT>, BatcherFactory<RequestT, ResponseT>) - Constructor for class com.google.api.gax.rpc.BatchingCallable
- BatchingCallSettings<ElementT,ElementResultT,RequestT,ResponseT> - Class in com.google.api.gax.batching
-
This is an extension of
UnaryCallSettings
class to configure aUnaryCallable
for calls to an API method that supports batching. - BatchingCallSettings<RequestT,ResponseT> - Class in com.google.api.gax.rpc
-
A settings class to configure a
UnaryCallable
for calls to an API method that supports batching. - BatchingCallSettings.Builder<ElementT,ElementResultT,RequestT,ResponseT> - Class in com.google.api.gax.batching
-
A base builder class for
BatchingCallSettings
. - BatchingCallSettings.Builder<RequestT,ResponseT> - Class in com.google.api.gax.rpc
- BatchingDescriptor<ElementT,ElementResultT,RequestT,ResponseT> - Interface in com.google.api.gax.batching
-
An adapter that packs and unpacks the elements in and out of batch requests and responses.
- BatchingDescriptor<RequestT,ResponseT> - Interface in com.google.api.gax.rpc
-
Interface which represents an object that transforms request/response data for the purposes of batching.
- BatchingException - Exception in com.google.api.gax.batching
-
Represents exception occurred during batching.
- BatchingFlowController<T> - Class in com.google.api.gax.batching
-
Wraps a
FlowController
for use by batching. - BatchingFlowController(FlowController, ElementCounter<T>, ElementCounter<T>) - Constructor for class com.google.api.gax.batching.BatchingFlowController
- BatchingRequestBuilder<ElementT,RequestT> - Interface in com.google.api.gax.batching
-
Adapter to pack individual elements into a larger batch request.
- BatchingSettings - Class in com.google.api.gax.batching
-
Represents the batching settings to use for an API method that is capable of batching.
- BatchingSettings() - Constructor for class com.google.api.gax.batching.BatchingSettings
- BatchingSettings.Builder - Class in com.google.api.gax.batching
-
See the class documentation of
BatchingSettings
for a description of the different values that can be set. - BatchingThreshold<E> - Interface in com.google.api.gax.batching
-
The interface representing a threshold to be used in ThresholdBatcher.
- BatchingThresholds - Class in com.google.api.gax.batching
-
Factory methods for general-purpose batching thresholds.
- BatchingThresholds() - Constructor for class com.google.api.gax.batching.BatchingThresholds
- BatchMerger<B> - Interface in com.google.api.gax.batching
- batchRequestSent(long, long) - Method in interface com.google.api.gax.tracing.ApiTracer
-
Adds an annotation that a batch of writes has been flushed.
- batchRequestSent(long, long) - Method in class com.google.api.gax.tracing.BaseApiTracer
- batchRequestSent(long, long) - Method in class com.google.api.gax.tracing.OpencensusTracer
-
Adds an annotation that a batch of writes has been flushed.
- BIDI_STREAMING - com.google.api.gax.httpjson.ApiMethodDescriptor.MethodType
- BidiStream<RequestT,ResponseT> - Class in com.google.api.gax.rpc
-
A wrapper around a bidirectional stream.
- BidiStreaming - com.google.api.gax.tracing.ApiTracerFactory.OperationType
- bidiStreamingCall(ApiStreamObserver<ResponseT>) - Method in class com.google.api.gax.rpc.BidiStreamingCallable
-
Deprecated.Please use
BidiStreamingCallable.splitCall(ResponseObserver)
instead. - bidiStreamingCall(ApiStreamObserver<ResponseT>, ApiCallContext) - Method in class com.google.api.gax.rpc.BidiStreamingCallable
-
Deprecated.Please use
BidiStreamingCallable.splitCall(ResponseObserver, ApiCallContext)
instead. - BidiStreamingCallable<RequestT,ResponseT> - Class in com.google.api.gax.rpc
-
A BidiStreamingCallable is an immutable object which is capable of making RPC calls to bidirectional streaming API methods.
- BidiStreamingCallable() - Constructor for class com.google.api.gax.rpc.BidiStreamingCallable
- BidiStreamObserver<RequestT,ResponseT> - Interface in com.google.api.gax.rpc
- Block - com.google.api.gax.batching.FlowController.LimitExceededBehavior
-
Waits until the request can be made without exceeding the limit.
- blockingServerStreamingCall(RequestT) - Method in class com.google.api.gax.rpc.ServerStreamingCallable
-
Deprecated.Please use call() instead.
- blockingServerStreamingCall(RequestT, ApiCallContext) - Method in class com.google.api.gax.rpc.ServerStreamingCallable
-
Deprecated.Please use call() instead.
- build() - Method in class com.google.api.gax.batching.BatchingCallSettings.Builder
-
Builds the
BatchingCallSettings
object with provided configuration. - build() - Method in interface com.google.api.gax.batching.BatchingRequestBuilder
-
Returns the collected elements as a single client specific batch request.
- build() - Method in class com.google.api.gax.batching.BatchingSettings.Builder
-
Build the BatchingSettings object.
- build() - Method in class com.google.api.gax.batching.DynamicFlowControlSettings.Builder
- build() - Method in class com.google.api.gax.batching.FlowControlSettings.Builder
- build() - Method in interface com.google.api.gax.batching.RequestBuilder
- build() - Method in class com.google.api.gax.batching.ThresholdBatcher.Builder
-
Build the ThresholdBatcher.
- build() - Method in class com.google.api.gax.core.GoogleCredentialsProvider.Builder
- build() - Method in class com.google.api.gax.core.InstantiatingExecutorProvider.Builder
- build() - Method in class com.google.api.gax.grpc.ChannelPoolSettings.Builder
- build() - Method in class com.google.api.gax.grpc.GrpcCallSettings.Builder
- build() - Method in class com.google.api.gax.grpc.GrpcTransportChannel.Builder
- build() - Method in class com.google.api.gax.grpc.InstantiatingGrpcChannelProvider.Builder
- build() - Method in class com.google.api.gax.httpjson.ApiMethodDescriptor.Builder
- build() - Method in class com.google.api.gax.httpjson.HttpJsonCallOptions.Builder
- build() - Method in class com.google.api.gax.httpjson.HttpJsonCallSettings.Builder
- build() - Method in class com.google.api.gax.httpjson.HttpJsonOperationSnapshot.Builder
- build() - Method in class com.google.api.gax.httpjson.HttpJsonTransportChannel.Builder
- build() - Method in class com.google.api.gax.httpjson.InstantiatingHttpJsonChannelProvider.Builder
- build() - Method in class com.google.api.gax.httpjson.longrunning.OperationsSettings.Builder
- build() - Method in class com.google.api.gax.httpjson.longrunning.stub.OperationsStubSettings.Builder
- build() - Method in class com.google.api.gax.httpjson.ManagedHttpJsonChannel.Builder
- build() - Method in class com.google.api.gax.httpjson.ProtoMessageRequestFormatter.Builder
- build() - Method in class com.google.api.gax.httpjson.ProtoMessageResponseParser.Builder
- build() - Method in class com.google.api.gax.retrying.RetrySettings.Builder
- build() - Method in class com.google.api.gax.retrying.TimedAttemptSettings.Builder
- build() - Method in class com.google.api.gax.rpc.ApiClientHeaderProvider.Builder
- build() - Method in class com.google.api.gax.rpc.BatchingCallSettings.Builder
- build() - Method in class com.google.api.gax.rpc.ClientContext.Builder
- build() - Method in class com.google.api.gax.rpc.ClientSettings.Builder
- build() - Method in class com.google.api.gax.rpc.ErrorDetails.Builder
- build() - Method in class com.google.api.gax.rpc.OperationCallSettings.Builder
- build() - Method in class com.google.api.gax.rpc.PagedCallSettings.Builder
- build() - Method in class com.google.api.gax.rpc.RequestParamsBuilder
- build() - Method in class com.google.api.gax.rpc.ServerStreamingCallSettings.Builder
- build() - Method in class com.google.api.gax.rpc.StreamingCallSettings.Builder
- build() - Method in class com.google.api.gax.rpc.StubSettings.Builder
- build() - Method in class com.google.api.gax.rpc.UnaryCallSettings.Builder
-
Builds an instance of the containing class.
- build() - Method in class com.google.longrunning.OperationsSettings.Builder
- build() - Method in class com.google.longrunning.stub.OperationsStubSettings.Builder
- builder() - Static method in class com.google.api.gax.grpc.ChannelPoolSettings
- builder() - Static method in class com.google.api.gax.rpc.ErrorDetails
- Builder() - Constructor for class com.google.api.gax.batching.BatchingSettings.Builder
- Builder() - Constructor for class com.google.api.gax.batching.DynamicFlowControlSettings.Builder
- Builder() - Constructor for class com.google.api.gax.batching.FlowControlSettings.Builder
- Builder() - Constructor for class com.google.api.gax.core.GoogleCredentialsProvider.Builder
- Builder() - Constructor for class com.google.api.gax.core.InstantiatingExecutorProvider.Builder
- Builder() - Constructor for class com.google.api.gax.grpc.ChannelPoolSettings.Builder
- Builder() - Constructor for class com.google.api.gax.grpc.GrpcTransportChannel.Builder
- Builder() - Constructor for class com.google.api.gax.httpjson.ApiMethodDescriptor.Builder
- Builder() - Constructor for class com.google.api.gax.httpjson.HttpJsonCallOptions.Builder
- Builder() - Constructor for class com.google.api.gax.httpjson.HttpJsonOperationSnapshot.Builder
- Builder() - Constructor for class com.google.api.gax.httpjson.HttpJsonTransportChannel.Builder
- Builder() - Constructor for class com.google.api.gax.httpjson.longrunning.OperationsSettings.Builder
- Builder() - Constructor for class com.google.api.gax.httpjson.longrunning.stub.OperationsStubSettings.Builder
- Builder() - Constructor for class com.google.api.gax.httpjson.ProtoMessageRequestFormatter.Builder
- Builder() - Constructor for class com.google.api.gax.httpjson.ProtoMessageResponseParser.Builder
- Builder() - Constructor for class com.google.api.gax.retrying.RetrySettings.Builder
- Builder() - Constructor for class com.google.api.gax.retrying.TimedAttemptSettings.Builder
- Builder() - Constructor for class com.google.api.gax.rpc.ApiClientHeaderProvider.Builder
- Builder() - Constructor for class com.google.api.gax.rpc.ClientContext.Builder
- Builder() - Constructor for class com.google.api.gax.rpc.ClientSettings.Builder
- Builder() - Constructor for class com.google.api.gax.rpc.ErrorDetails.Builder
- Builder() - Constructor for class com.google.api.gax.rpc.OperationCallSettings.Builder
- Builder() - Constructor for class com.google.api.gax.rpc.StreamingCallSettings.Builder
- Builder() - Constructor for class com.google.api.gax.rpc.StubSettings.Builder
- Builder() - Constructor for class com.google.api.gax.rpc.UnaryCallSettings.Builder
- Builder() - Constructor for class com.google.longrunning.OperationsSettings.Builder
- Builder() - Constructor for class com.google.longrunning.stub.OperationsStubSettings.Builder
- Builder(OperationsSettings) - Constructor for class com.google.api.gax.httpjson.longrunning.OperationsSettings.Builder
- Builder(OperationsStubSettings) - Constructor for class com.google.api.gax.httpjson.longrunning.stub.OperationsStubSettings.Builder
- Builder(OperationsStubSettings.Builder) - Constructor for class com.google.api.gax.httpjson.longrunning.OperationsSettings.Builder
- Builder(BatchingCallSettings<RequestT, ResponseT>) - Constructor for class com.google.api.gax.rpc.BatchingCallSettings.Builder
- Builder(BatchingDescriptor<RequestT, ResponseT>) - Constructor for class com.google.api.gax.rpc.BatchingCallSettings.Builder
- Builder(ClientContext) - Constructor for class com.google.api.gax.httpjson.longrunning.OperationsSettings.Builder
- Builder(ClientContext) - Constructor for class com.google.api.gax.httpjson.longrunning.stub.OperationsStubSettings.Builder
- Builder(ClientContext) - Constructor for class com.google.api.gax.rpc.StubSettings.Builder
- Builder(ClientContext) - Constructor for class com.google.longrunning.OperationsSettings.Builder
- Builder(ClientContext) - Constructor for class com.google.longrunning.stub.OperationsStubSettings.Builder
- Builder(ClientSettings) - Constructor for class com.google.api.gax.rpc.ClientSettings.Builder
-
Create a builder from a ClientSettings object.
- Builder(OperationCallSettings<RequestT, ResponseT, MetadataT>) - Constructor for class com.google.api.gax.rpc.OperationCallSettings.Builder
- Builder(PagedCallSettings<RequestT, ResponseT, PagedListResponseT>) - Constructor for class com.google.api.gax.rpc.PagedCallSettings.Builder
- Builder(PagedListResponseFactory<RequestT, ResponseT, PagedListResponseT>) - Constructor for class com.google.api.gax.rpc.PagedCallSettings.Builder
- Builder(StreamingCallSettings<RequestT, ResponseT>) - Constructor for class com.google.api.gax.rpc.StreamingCallSettings.Builder
- Builder(StubSettings) - Constructor for class com.google.api.gax.rpc.StubSettings.Builder
-
Create a builder from a StubSettings object.
- Builder(StubSettings.Builder) - Constructor for class com.google.api.gax.rpc.ClientSettings.Builder
-
Create a builder from a StubSettings object.
- Builder(UnaryCallSettings<RequestT, ResponseT>) - Constructor for class com.google.api.gax.rpc.UnaryCallSettings.Builder
- Builder(OperationsSettings) - Constructor for class com.google.longrunning.OperationsSettings.Builder
- Builder(OperationsStubSettings) - Constructor for class com.google.longrunning.stub.OperationsStubSettings.Builder
- Builder(OperationsStubSettings.Builder) - Constructor for class com.google.longrunning.OperationsSettings.Builder
C
- call() - Method in class com.google.api.gax.rpc.BidiStreamingCallable
-
Send requests and iterate over server responses.
- call(ApiCallContext) - Method in class com.google.api.gax.rpc.BidiStreamingCallable
-
Send requests and iterate over server responses.
- call(BidiStreamObserver<RequestT, ResponseT>) - Method in class com.google.api.gax.rpc.BidiStreamingCallable
-
Listens to server responses and send requests when the network is free.
- call(BidiStreamObserver<RequestT, ResponseT>, ApiCallContext) - Method in class com.google.api.gax.rpc.BidiStreamingCallable
-
Listens to server responses and send requests when the network is free.
- call(RequestT) - Method in class com.google.api.gax.rpc.OperationCallable
-
Same as
OperationCallable.call(Object, ApiCallContext)
, with a null context. - call(RequestT) - Method in class com.google.api.gax.rpc.ServerStreamingCallable
-
Conduct a iteration server streaming call.
- call(RequestT) - Method in class com.google.api.gax.rpc.UnaryCallable
-
Same as
UnaryCallable.call(Object, ApiCallContext)
, with a null context. - call(RequestT, ApiCallContext) - Method in class com.google.api.gax.rpc.OperationCallable
-
Perform a call synchronously.
- call(RequestT, ApiCallContext) - Method in class com.google.api.gax.rpc.ServerStreamingCallable
-
Conduct a server streaming call with the given
ApiCallContext
. - call(RequestT, ApiCallContext) - Method in class com.google.api.gax.rpc.UnaryCallable
-
Perform a call synchronously.
- call(RequestT, ResponseObserver<ResponseT>) - Method in class com.google.api.gax.rpc.ServerStreamingCallable
-
Conduct a server streaming call
- call(RequestT, ResponseObserver<ResponseT>, ApiCallContext) - Method in class com.google.api.gax.rpc.ServerStreamingCallable
-
Conduct a server streaming call with the given
ApiCallContext
. - call(RequestT, ResponseObserver<ResponseT>, ApiCallContext) - Method in class com.google.api.gax.tracing.TracedServerStreamingCallable
- Callables - Class in com.google.api.gax.rpc
-
Class with utility methods to create callable objects using provided settings.
- callAndTranslateApiException(ApiFuture<ResponseT>) - Static method in class com.google.api.gax.rpc.ApiExceptions
-
Invokes
Future.get()
on the given future, and if the call throws an exception (which will beUncheckedExecutionException
), the exception is processed in the following way: If the exception cause is a RuntimeException, the RuntimeException is rethrown. - cancel() - Method in class com.google.api.gax.rpc.ServerStream
-
Cleanly cancels a partially consumed stream.
- cancel() - Method in interface com.google.api.gax.rpc.StreamController
-
Cancel the stream early.
- cancel(boolean) - Method in class com.google.api.gax.longrunning.OperationFutureImpl
- cancel(boolean) - Method in class com.google.api.gax.retrying.NonCancellableFuture
- cancel(String) - Method in class com.google.api.gax.rpc.OperationCallable
-
Sends a cancellation request to the server for the operation with name
operationName
. - cancel(String, ApiCallContext) - Method in class com.google.api.gax.rpc.OperationCallable
-
Sends a cancellation request to the server for the operation with name
operationName
. - cancel(String, ApiCallContext) - Method in class com.google.api.gax.tracing.TracedOperationCallable
-
Wrap operation cancellation in a
ApiTracerFactory.OperationType.Unary
trace. - cancel(String, Throwable) - Method in class com.google.api.gax.httpjson.ForwardingHttpJsonClientCall
- cancel(String, Throwable) - Method in class com.google.api.gax.httpjson.HttpJsonClientCall
-
Prevent any further processing for this
HttpJsonClientCall
. - CANCELLED - com.google.api.gax.rpc.StatusCode.Code
- CancelledException - Exception in com.google.api.gax.rpc
-
The exception thrown when the operation was cancelled (typically by the caller).
- CancelledException(String, Throwable, StatusCode, boolean) - Constructor for exception com.google.api.gax.rpc.CancelledException
- CancelledException(Throwable, StatusCode, boolean) - Constructor for exception com.google.api.gax.rpc.CancelledException
- CancelledException(Throwable, StatusCode, boolean, ErrorDetails) - Constructor for exception com.google.api.gax.rpc.CancelledException
- cancelOperation(CancelOperationRequest) - Method in class com.google.api.gax.httpjson.longrunning.OperationsClient
-
Starts asynchronous cancellation on a long-running operation.
- cancelOperation(String) - Method in class com.google.api.gax.httpjson.longrunning.OperationsClient
-
Starts asynchronous cancellation on a long-running operation.
- cancelOperation(String) - Method in class com.google.longrunning.OperationsClient
-
Starts asynchronous cancellation on a long-running operation.
- cancelOperationCallable() - Method in class com.google.api.gax.httpjson.HttpJsonLongRunningClient
-
Returns a
UnaryCallable
which can issue calls to cancel an operation. - cancelOperationCallable() - Method in class com.google.api.gax.httpjson.longrunning.OperationsClient
-
Starts asynchronous cancellation on a long-running operation.
- cancelOperationCallable() - Method in class com.google.api.gax.httpjson.longrunning.stub.HttpJsonOperationsStub
- cancelOperationCallable() - Method in class com.google.api.gax.httpjson.longrunning.stub.OperationsStub
- cancelOperationCallable() - Method in interface com.google.api.gax.rpc.LongRunningClient
-
Returns a
UnaryCallable
which can issue calls to cancel an operation. - cancelOperationCallable() - Method in class com.google.longrunning.OperationsClient
-
Starts asynchronous cancellation on a long-running operation.
- cancelOperationCallable() - Method in class com.google.longrunning.stub.GrpcOperationsStub
- cancelOperationCallable() - Method in class com.google.longrunning.stub.OperationsStub
- cancelOperationSettings() - Method in class com.google.api.gax.httpjson.longrunning.OperationsSettings.Builder
-
Returns the builder for the settings used for calls to cancel.
- cancelOperationSettings() - Method in class com.google.api.gax.httpjson.longrunning.OperationsSettings
-
Returns the object with the settings used for calls to cancel.
- cancelOperationSettings() - Method in class com.google.api.gax.httpjson.longrunning.stub.OperationsStubSettings.Builder
-
Returns the builder for the settings used for calls to cancel.
- cancelOperationSettings() - Method in class com.google.api.gax.httpjson.longrunning.stub.OperationsStubSettings
-
Returns the object with the settings used for calls to cancel.
- cancelOperationSettings() - Method in class com.google.longrunning.OperationsSettings.Builder
-
Returns the builder for the settings used for calls to cancelOperation.
- cancelOperationSettings() - Method in class com.google.longrunning.OperationsSettings
-
Returns the object with the settings used for calls to cancelOperation.
- cancelOperationSettings() - Method in class com.google.longrunning.stub.OperationsStubSettings.Builder
-
Returns the builder for the settings used for calls to cancelOperation.
- cancelOperationSettings() - Method in class com.google.longrunning.stub.OperationsStubSettings
-
Returns the object with the settings used for calls to cancelOperation.
- canResume() - Method in exception com.google.api.gax.retrying.ServerStreamingAttemptException
-
If the
StreamResumptionStrategy
supports resuming after this error. - canResume() - Method in class com.google.api.gax.retrying.SimpleStreamResumptionStrategy
- canResume() - Method in interface com.google.api.gax.retrying.StreamResumptionStrategy
-
If a resume request can be created.
- ChannelFactory - Interface in com.google.api.gax.grpc
-
This interface represents a factory for creating one ManagedChannel
- ChannelPoolSettings - Class in com.google.api.gax.grpc
-
Settings to control
ChannelPool
behavior. - ChannelPoolSettings() - Constructor for class com.google.api.gax.grpc.ChannelPoolSettings
- ChannelPoolSettings.Builder - Class in com.google.api.gax.grpc
- ChannelPrimer - Interface in com.google.api.gax.grpc
-
An interface to prepare a ManagedChannel for normal requests by priming the channel
- CLIENT_STREAMING - com.google.api.gax.httpjson.ApiMethodDescriptor.MethodType
- ClientContext - Class in com.google.api.gax.rpc
-
Encapsulates client state, including executor, credentials, and transport channel.
- ClientContext() - Constructor for class com.google.api.gax.rpc.ClientContext
- ClientContext.Builder - Class in com.google.api.gax.rpc
- ClientSettings<SettingsT extends ClientSettings<SettingsT>> - Class in com.google.api.gax.rpc
-
A base settings class to configure a client class.
- ClientSettings(ClientSettings.Builder) - Constructor for class com.google.api.gax.rpc.ClientSettings
-
Constructs an instance of ClientSettings.
- ClientSettings.Builder<SettingsT extends ClientSettings<SettingsT>,B extends ClientSettings.Builder<SettingsT,B>> - Class in com.google.api.gax.rpc
- ClientStream<RequestT> - Interface in com.google.api.gax.rpc
-
A wrapper used to send requests to the server.
- ClientStreaming - com.google.api.gax.tracing.ApiTracerFactory.OperationType
- clientStreamingCall(ApiStreamObserver<ResponseT>) - Method in class com.google.api.gax.rpc.ClientStreamingCallable
-
Conduct a client streaming call
- clientStreamingCall(ApiStreamObserver<ResponseT>, ApiCallContext) - Method in class com.google.api.gax.rpc.ClientStreamingCallable
-
Conduct a client streaming call with the given
ApiCallContext
- clientStreamingCall(ApiStreamObserver<ResponseT>, ApiCallContext) - Method in class com.google.api.gax.tracing.TracedClientStreamingCallable
- ClientStreamingCallable<RequestT,ResponseT> - Class in com.google.api.gax.rpc
-
A ClientStreamingCallable is an immutable object which is capable of making RPC calls to client streaming API methods.
- ClientStreamingCallable() - Constructor for class com.google.api.gax.rpc.ClientStreamingCallable
- ClientStreamReadyObserver<V> - Interface in com.google.api.gax.rpc
-
A callback used to report that the
ClientStream
is ready to send more messages. - close() - Method in interface com.google.api.gax.batching.Batcher
-
Closes this Batcher by preventing new elements from being added, and then flushing the existing elements.
- close() - Method in class com.google.api.gax.batching.BatcherImpl
-
Closes this Batcher by preventing new elements from being added, and then flushing the existing elements.
- close() - Method in class com.google.api.gax.core.BackgroundResourceAggregation
- close() - Method in class com.google.api.gax.core.BaseBackgroundResource
- close() - Method in class com.google.api.gax.core.ExecutorAsBackgroundResource
- close() - Method in class com.google.api.gax.grpc.GrpcTransportChannel
- close() - Method in class com.google.api.gax.httpjson.HttpJsonTransportChannel
- close() - Method in class com.google.api.gax.httpjson.longrunning.OperationsClient
- close() - Method in class com.google.api.gax.httpjson.longrunning.stub.HttpJsonOperationsStub
- close() - Method in class com.google.api.gax.httpjson.longrunning.stub.OperationsStub
- close() - Method in class com.google.api.gax.httpjson.ManagedHttpJsonChannel
- close() - Method in class com.google.api.gax.rpc.Watchdog
- close() - Method in interface com.google.api.gax.tracing.ApiTracer.Scope
- close() - Method in class com.google.longrunning.OperationsClient
- close() - Method in class com.google.longrunning.stub.GrpcOperationsStub
- close() - Method in class com.google.longrunning.stub.OperationsStub
- closeAsync() - Method in interface com.google.api.gax.batching.Batcher
-
Closes this Batcher by preventing new elements from being added, and then sending outstanding elements.
- closeAsync() - Method in class com.google.api.gax.batching.BatcherImpl
- closeSend() - Method in class com.google.api.gax.rpc.BidiStream
-
Closes the sending side of the stream.
- closeSend() - Method in interface com.google.api.gax.rpc.ClientStream
-
Closes the stream.
- closeSendWithError(Throwable) - Method in class com.google.api.gax.rpc.BidiStream
-
Closes the sending side of the stream with error.
- closeSendWithError(Throwable) - Method in interface com.google.api.gax.rpc.ClientStream
-
Closes the stream with an error.
- com.google.api.gax.batching - package com.google.api.gax.batching
- com.google.api.gax.core - package com.google.api.gax.core
- com.google.api.gax.grpc - package com.google.api.gax.grpc
- com.google.api.gax.httpjson - package com.google.api.gax.httpjson
- com.google.api.gax.httpjson.longrunning - package com.google.api.gax.httpjson.longrunning
- com.google.api.gax.httpjson.longrunning.stub - package com.google.api.gax.httpjson.longrunning.stub
- com.google.api.gax.longrunning - package com.google.api.gax.longrunning
- com.google.api.gax.nativeimage - package com.google.api.gax.nativeimage
- com.google.api.gax.paging - package com.google.api.gax.paging
- com.google.api.gax.retrying - package com.google.api.gax.retrying
- com.google.api.gax.rpc - package com.google.api.gax.rpc
- com.google.api.gax.rpc.internal - package com.google.api.gax.rpc.internal
- com.google.api.gax.rpc.mtls - package com.google.api.gax.rpc.mtls
- com.google.api.gax.tracing - package com.google.api.gax.tracing
- com.google.longrunning - package com.google.longrunning
-
A client to Google Long Running Operations API.
- com.google.longrunning.stub - package com.google.longrunning.stub
- compareTo(FlowControlEventStats.FlowControlEvent) - Method in class com.google.api.gax.batching.FlowControlEventStats.FlowControlEvent
- connectionSelected(String) - Method in interface com.google.api.gax.tracing.ApiTracer
-
Annotates the operation with selected connection id from the
ChannelPool
. - connectionSelected(String) - Method in class com.google.api.gax.tracing.BaseApiTracer
- connectionSelected(String) - Method in class com.google.api.gax.tracing.OpencensusTracer
-
Annotates the operation with selected connection id from the
ChannelPool
. - ContextAwareMetadataJson - Class in com.google.api.gax.rpc.mtls
-
Data class representing context_aware_metadata.json file.
- ContextAwareMetadataJson() - Constructor for class com.google.api.gax.rpc.mtls.ContextAwareMetadataJson
- copyWithZeroedValue() - Method in interface com.google.api.gax.batching.BatchingThreshold
-
Make a copy of this threshold but with the accumulated value zeroed.
- copyWithZeroedValue() - Method in class com.google.api.gax.batching.NumericThreshold
- count(E) - Method in interface com.google.api.gax.batching.ElementCounter
-
Provides the numerical count associated with the given object.
- countBytes(ElementT) - Method in interface com.google.api.gax.batching.BatchingDescriptor
-
Returns the size of the passed element object in bytes.
- countBytes(RequestT) - Method in interface com.google.api.gax.rpc.BatchingDescriptor
-
Returns the size in bytes of this request.
- countElements(RequestT) - Method in interface com.google.api.gax.rpc.BatchingDescriptor
-
Returns the number of elements contained in this request.
- create() - Static method in class com.google.api.gax.core.NoCredentialsProvider
- create() - Static method in class com.google.api.gax.httpjson.longrunning.OperationsClient
-
Constructs an instance of OperationsClient with default settings.
- create() - Static method in class com.google.api.gax.httpjson.ProtoRestSerializer
-
Creates a new instance of ProtoRestSerializer.
- create() - Static method in class com.google.api.gax.rpc.BatchedFuture
-
Get a new instance.
- create() - Static method in class com.google.api.gax.rpc.InstantiatingWatchdogProvider
- create() - Static method in class com.google.api.gax.rpc.RequestParamsBuilder
- create(long) - Static method in class com.google.api.gax.batching.BatchingThresholds
-
Creates an ImmutableList containing only a single threshold which counts the number of elements.
- create(ApiClock, Duration, ScheduledExecutorService) - Static method in class com.google.api.gax.rpc.Watchdog
-
returns a Watchdog which is scheduled at the provided interval.
- create(BackgroundResource) - Static method in class com.google.api.gax.httpjson.longrunning.OperationsClient
-
Constructs an instance of OperationsClient, using the given stub for making calls.
- create(ApiMethodDescriptor<RequestT, ResponseT>) - Static method in class com.google.api.gax.httpjson.HttpJsonCallSettings
- create(OperationsSettings) - Static method in class com.google.api.gax.httpjson.longrunning.OperationsClient
-
Constructs an instance of OperationsClient, using the given settings.
- create(OperationsStub) - Static method in class com.google.api.gax.httpjson.longrunning.OperationsClient
-
Constructs an instance of OperationsClient, using the given stub for making calls.
- create(OperationsStubSettings) - Static method in class com.google.api.gax.httpjson.longrunning.OperationsSettings
- create(OperationsStubSettings) - Static method in class com.google.api.gax.httpjson.longrunning.stub.HttpJsonOperationsStub
- create(ManagedHttpJsonChannel) - Static method in class com.google.api.gax.httpjson.HttpJsonTransportChannel
- create(RetrySettings) - Static method in class com.google.api.gax.longrunning.OperationTimedPollAlgorithm
-
Creates the polling algorithm, using the default
NanoClock
for time computations. - create(RetrySettings, ApiClock) - Static method in class com.google.api.gax.longrunning.OperationTimedPollAlgorithm
- create(ClientContext) - Static method in class com.google.api.gax.httpjson.longrunning.stub.HttpJsonOperationsStub
- create(ClientContext) - Static method in class com.google.longrunning.stub.GrpcOperationsStub
- create(ClientContext, GrpcStubCallableFactory) - Static method in class com.google.longrunning.stub.GrpcOperationsStub
- create(ClientContext, HttpJsonStubCallableFactory) - Static method in class com.google.api.gax.httpjson.longrunning.stub.HttpJsonOperationsStub
- create(ClientContext, HttpJsonStubCallableFactory, TypeRegistry) - Static method in class com.google.api.gax.httpjson.longrunning.stub.HttpJsonOperationsStub
- create(ClientSettings) - Static method in class com.google.api.gax.rpc.ClientContext
-
Instantiates the executor, credentials, and transport context based on the given client settings.
- create(StubSettings) - Static method in class com.google.api.gax.rpc.ClientContext
-
Instantiates the executor, credentials, and transport context based on the given client settings.
- create(TransportChannel) - Static method in class com.google.api.gax.rpc.FixedTransportChannelProvider
-
Creates a FixedTransportChannelProvider.
- create(UnaryCallable<InnerRequestT, InnerResponseT>, ApiFunction<OuterRequestT, InnerRequestT>, ApiFunction<InnerResponseT, OuterResponseT>) - Static method in class com.google.api.gax.rpc.TranslatingUnaryCallable
- create(UnaryCallable<RequestT, ResponseT>, PagedListDescriptor<RequestT, ResponseT, ResourceT>, RequestT, ApiCallContext) - Static method in class com.google.api.gax.rpc.PageContext
- create(Watchdog) - Static method in class com.google.api.gax.rpc.FixedWatchdogProvider
- create(Credentials) - Static method in class com.google.api.gax.core.FixedCredentialsProvider
-
Creates a FixedCredentialsProvider.
- create(Operation) - Static method in class com.google.api.gax.httpjson.HttpJsonOperationSnapshot
- create(OperationsSettings) - Static method in class com.google.longrunning.OperationsClient
-
Constructs an instance of OperationsClient, using the given settings.
- create(OperationsStub) - Static method in class com.google.longrunning.OperationsClient
-
Constructs an instance of OperationsClient, using the given stub for making calls.
- create(OperationsStubSettings) - Static method in class com.google.longrunning.OperationsSettings
- create(OperationsStubSettings) - Static method in class com.google.longrunning.stub.GrpcOperationsStub
- create(ElementT, SettableApiFuture<ElementResultT>) - Static method in class com.google.api.gax.batching.BatchEntry
-
Returns a new BatchEntry
- create(ManagedChannel) - Static method in class com.google.api.gax.grpc.GrpcTransportChannel
- create(MethodDescriptor<RequestT, ResponseT>) - Static method in class com.google.api.gax.grpc.GrpcCallSettings
- create(Class<ResponseT>) - Static method in class com.google.api.gax.grpc.ProtoOperationTransformers.MetadataTransformer
- create(Class<ResponseT>) - Static method in class com.google.api.gax.grpc.ProtoOperationTransformers.ResponseTransformer
- create(Class<ResponseT>) - Static method in class com.google.api.gax.httpjson.ProtoOperationTransformers.MetadataTransformer
- create(Class<ResponseT>) - Static method in class com.google.api.gax.httpjson.ProtoOperationTransformers.ResponseTransformer
- create(String) - Method in interface com.google.api.gax.httpjson.PollingRequestFactory
-
Creates a polling request message from a
compoundOperationId
. - create(String) - Static method in class com.google.api.gax.rpc.ApiCallContext.Key
-
Factory method for creating instances of
ApiCallContext.Key
. - create(String...) - Static method in class com.google.api.gax.rpc.FixedHeaderProvider
- create(String, String) - Static method in class com.google.api.gax.httpjson.HttpJsonHeaderEnhancers
- create(ScheduledExecutorService) - Static method in class com.google.api.gax.core.FixedExecutorProvider
-
Creates a FixedExecutorProvider.
- create(Map<String, String>) - Static method in class com.google.api.gax.rpc.FixedHeaderProvider
-
Creates a FixedHeaderProvider.
- create(RequestT, OperationT) - Method in interface com.google.api.gax.httpjson.OperationSnapshotFactory
- createAsync(PageContext<ListOperationsRequest, ListOperationsResponse, Operation>, ApiFuture<ListOperationsResponse>) - Static method in class com.google.api.gax.httpjson.longrunning.OperationsClient.ListOperationsPagedResponse
- createAsync(PageContext<ListOperationsRequest, ListOperationsResponse, Operation>, ApiFuture<ListOperationsResponse>) - Static method in class com.google.longrunning.OperationsClient.ListOperationsPagedResponse
- createBaseUnaryCallable(GrpcCallSettings<RequestT, ResponseT>, UnaryCallSettings<?, ?>, ClientContext) - Static method in class com.google.api.gax.grpc.GrpcCallableFactory
-
Create a Unary callable object with minimal grpc-specific functionality.
- createBaseUnaryCallable(HttpJsonCallSettings<RequestT, ResponseT>, UnaryCallSettings<?, ?>, ClientContext) - Static method in class com.google.api.gax.httpjson.HttpJsonCallableFactory
-
Create a Unary callable object with minimal http/json-specific functionality.
- createBatchingCallable(GrpcCallSettings<RequestT, ResponseT>, BatchingCallSettings<RequestT, ResponseT>, ClientContext) - Static method in class com.google.api.gax.grpc.GrpcCallableFactory
-
Create a callable object that represents a batching API method.
- createBatchingCallable(GrpcCallSettings<RequestT, ResponseT>, BatchingCallSettings<RequestT, ResponseT>, ClientContext) - Method in interface com.google.api.gax.grpc.GrpcStubCallableFactory
-
Create a callable object that represents a batching API method.
- createBatchingCallable(GrpcCallSettings<RequestT, ResponseT>, BatchingCallSettings<RequestT, ResponseT>, ClientContext) - Method in class com.google.longrunning.stub.GrpcOperationsCallableFactory
- createBatchingCallable(HttpJsonCallSettings<RequestT, ResponseT>, BatchingCallSettings<RequestT, ResponseT>, ClientContext) - Static method in class com.google.api.gax.httpjson.HttpJsonCallableFactory
-
Create a callable object that represents a batching API method.
- createBatchingCallable(HttpJsonCallSettings<RequestT, ResponseT>, BatchingCallSettings<RequestT, ResponseT>, ClientContext) - Method in interface com.google.api.gax.httpjson.HttpJsonStubCallableFactory
-
Create a callable object that represents a batching API method.
- createBatchingCallable(HttpJsonCallSettings<RequestT, ResponseT>, BatchingCallSettings<RequestT, ResponseT>, ClientContext) - Method in class com.google.api.gax.httpjson.longrunning.stub.HttpJsonOperationsCallableFactory
- createBidiStreamingCallable(GrpcCallSettings<RequestT, ResponseT>, StreamingCallSettings<RequestT, ResponseT>, ClientContext) - Static method in class com.google.api.gax.grpc.GrpcCallableFactory
-
Create a bidirectional streaming callable object with grpc-specific functionality.
- createBidiStreamingCallable(GrpcCallSettings<RequestT, ResponseT>, StreamingCallSettings<RequestT, ResponseT>, ClientContext) - Method in interface com.google.api.gax.grpc.GrpcStubCallableFactory
-
Create a bidirectional streaming callable object with grpc-specific functionality.
- createBidiStreamingCallable(GrpcCallSettings<RequestT, ResponseT>, StreamingCallSettings<RequestT, ResponseT>, ClientContext) - Method in class com.google.longrunning.stub.GrpcOperationsCallableFactory
- createBidiStreamingCallable(GrpcCallSettings<RequestT, ResponseT>, Set<StatusCode.Code>) - Static method in class com.google.api.gax.grpc.GrpcRawCallableFactory
-
Create a bidirectional streaming callable object with grpc-specific functionality.
- createClientStreamingCallable(GrpcCallSettings<RequestT, ResponseT>, StreamingCallSettings<RequestT, ResponseT>, ClientContext) - Static method in class com.google.api.gax.grpc.GrpcCallableFactory
-
Create a client-streaming callable object with grpc-specific functionality.
- createClientStreamingCallable(GrpcCallSettings<RequestT, ResponseT>, StreamingCallSettings<RequestT, ResponseT>, ClientContext) - Method in interface com.google.api.gax.grpc.GrpcStubCallableFactory
-
Create a client-streaming callable object with grpc-specific functionality.
- createClientStreamingCallable(GrpcCallSettings<RequestT, ResponseT>, StreamingCallSettings<RequestT, ResponseT>, ClientContext) - Method in class com.google.longrunning.stub.GrpcOperationsCallableFactory
- createClientStreamingCallable(GrpcCallSettings<RequestT, ResponseT>, Set<StatusCode.Code>) - Static method in class com.google.api.gax.grpc.GrpcRawCallableFactory
-
Create a client-streaming callable object with grpc-specific functionality.
- createCollection(List<OperationsClient.ListOperationsPage>, int) - Method in class com.google.api.gax.httpjson.longrunning.OperationsClient.ListOperationsFixedSizeCollection
- createCollection(List<OperationsClient.ListOperationsPage>, int) - Method in class com.google.longrunning.OperationsClient.ListOperationsFixedSizeCollection
- createCollection(List<PageT>, int) - Method in class com.google.api.gax.paging.AbstractFixedSizeCollection
- createContextWithHandlers() - Method in class com.google.api.gax.grpc.GrpcResponseMetadata
-
Constructs a new call context and sets the CallOptions to add handlers to retrieve the headers and trailers, and make them available via the getMetadata and getTrailingMetadata methods.
- createDefault() - Static method in class com.google.api.gax.grpc.GrpcCallContext
-
Returns an empty instance with a null channel and default
CallOptions
. - createDefault() - Static method in class com.google.api.gax.httpjson.HttpJsonCallContext
-
Returns an empty instance.
- createException(String, Throwable, StatusCode, boolean) - Static method in class com.google.api.gax.rpc.ApiExceptionFactory
- createException(Throwable, StatusCode, boolean) - Static method in class com.google.api.gax.rpc.ApiExceptionFactory
- createException(Throwable, StatusCode, boolean, ErrorDetails) - Static method in class com.google.api.gax.rpc.ApiExceptionFactory
- createFirstAttempt() - Method in class com.google.api.gax.retrying.ExponentialRetryAlgorithm
-
Creates a first attempt
TimedAttemptSettings
. - createFirstAttempt() - Method in class com.google.api.gax.retrying.RetryAlgorithm
-
Deprecated.
- createFirstAttempt() - Method in interface com.google.api.gax.retrying.TimedRetryAlgorithm
-
Same as
TimedRetryAlgorithmWithContext.createFirstAttempt(RetryingContext)
, but without aRetryingContext
. - createFirstAttempt(RetryingContext) - Method in class com.google.api.gax.retrying.ExponentialRetryAlgorithm
-
Creates a first attempt
TimedAttemptSettings
. - createFirstAttempt(RetryingContext) - Method in class com.google.api.gax.retrying.RetryAlgorithm
-
Creates a first attempt
TimedAttemptSettings
. - createFirstAttempt(RetryingContext) - Method in interface com.google.api.gax.retrying.TimedRetryAlgorithmWithContext
-
Creates a first attempt
TimedAttemptSettings
. - createFuture(Callable<ResponseT>) - Method in class com.google.api.gax.retrying.DirectRetryingExecutor
-
Creates a
RetryingFuture
, which is a facade, returned to the client code to wait for any retriable operation to complete. - createFuture(Callable<ResponseT>) - Method in interface com.google.api.gax.retrying.RetryingExecutor
-
Creates the
RetryingFuture
, which is a facade, returned to the client code to wait for any retriable operation to complete. - createFuture(Callable<ResponseT>) - Method in class com.google.api.gax.retrying.ScheduledRetryingExecutor
-
Creates a
RetryingFuture
, which is a facade, returned to the client code to wait for any retriable operation to complete. - createFuture(Callable<ResponseT>, RetryingContext) - Method in class com.google.api.gax.retrying.DirectRetryingExecutor
-
Creates a
RetryingFuture
, which is a facade, returned to the client code to wait for any retriable operation to complete. - createFuture(Callable<ResponseT>, RetryingContext) - Method in interface com.google.api.gax.retrying.RetryingExecutorWithContext
- createFuture(Callable<ResponseT>, RetryingContext) - Method in class com.google.api.gax.retrying.ScheduledRetryingExecutor
-
Creates a
RetryingFuture
, which is a facade, returned to the client code to wait for any retriable operation to complete. - createNew() - Method in class com.google.api.gax.retrying.SimpleStreamResumptionStrategy
- createNew() - Method in interface com.google.api.gax.retrying.StreamResumptionStrategy
-
Creates a new instance of this StreamResumptionStrategy without accumulated state
- createNextAttempt(RetryingContext, TimedAttemptSettings) - Method in class com.google.api.gax.retrying.ExponentialRetryAlgorithm
-
Creates a next attempt
TimedAttemptSettings
. - createNextAttempt(RetryingContext, TimedAttemptSettings) - Method in interface com.google.api.gax.retrying.TimedRetryAlgorithmWithContext
-
Creates a next attempt
TimedAttemptSettings
, which defines properties of the next attempt. - createNextAttempt(RetryingContext, Throwable, ResponseT, TimedAttemptSettings) - Method in class com.google.api.gax.retrying.BasicResultRetryAlgorithm
-
Always returns null, indicating that this algorithm does not provide any specific settings for the next attempt.
- createNextAttempt(RetryingContext, Throwable, ResponseT, TimedAttemptSettings) - Method in interface com.google.api.gax.retrying.ResultRetryAlgorithmWithContext
-
Creates a next attempt
TimedAttemptSettings
. - createNextAttempt(RetryingContext, Throwable, ResponseT, TimedAttemptSettings) - Method in class com.google.api.gax.retrying.RetryAlgorithm
-
Creates a next attempt
TimedAttemptSettings
. - createNextAttempt(RetryingContext, Throwable, ResponseT, TimedAttemptSettings) - Method in class com.google.api.gax.retrying.StreamingRetryAlgorithm
-
Creates a next attempt
TimedAttemptSettings
. - createNextAttempt(TimedAttemptSettings) - Method in class com.google.api.gax.retrying.ExponentialRetryAlgorithm
-
Creates a next attempt
TimedAttemptSettings
. - createNextAttempt(TimedAttemptSettings) - Method in interface com.google.api.gax.retrying.TimedRetryAlgorithm
- createNextAttempt(Throwable, OperationSnapshot, TimedAttemptSettings) - Method in class com.google.api.gax.longrunning.OperationResponsePollAlgorithm
- createNextAttempt(Throwable, ResponseT, TimedAttemptSettings) - Method in class com.google.api.gax.retrying.BasicResultRetryAlgorithm
-
Always returns null, indicating that this algorithm does not provide any specific settings for the next attempt.
- createNextAttempt(Throwable, ResponseT, TimedAttemptSettings) - Method in interface com.google.api.gax.retrying.ResultRetryAlgorithm
- createNextAttempt(Throwable, ResponseT, TimedAttemptSettings) - Method in class com.google.api.gax.retrying.RetryAlgorithm
-
Deprecated.
- createNextAttempt(Throwable, ResponseT, TimedAttemptSettings) - Method in class com.google.api.gax.retrying.StreamingRetryAlgorithm
-
Creates a next attempt
TimedAttemptSettings
. - createOperationCallable(GrpcCallSettings<RequestT, Operation>, OperationCallSettings<RequestT, ResponseT, MetadataT>, ClientContext, OperationsStub) - Static method in class com.google.api.gax.grpc.GrpcCallableFactory
-
Creates a callable object that represents a long-running operation.
- createOperationCallable(GrpcCallSettings<RequestT, Operation>, OperationCallSettings<RequestT, ResponseT, MetadataT>, ClientContext, OperationsStub) - Method in interface com.google.api.gax.grpc.GrpcStubCallableFactory
-
Creates a callable object that represents a long-running operation.
- createOperationCallable(GrpcCallSettings<RequestT, Operation>, OperationCallSettings<RequestT, ResponseT, MetadataT>, ClientContext, OperationsStub) - Method in class com.google.longrunning.stub.GrpcOperationsCallableFactory
- createOperationCallable(HttpJsonCallSettings<RequestT, Operation>, OperationCallSettings<RequestT, ResponseT, MetadataT>, ClientContext, BackgroundResource) - Method in class com.google.api.gax.httpjson.longrunning.stub.HttpJsonOperationsCallableFactory
- createOperationCallable(HttpJsonCallSettings<RequestT, OperationT>, OperationCallSettings<RequestT, ResponseT, MetadataT>, ClientContext, OperationsStub) - Method in interface com.google.api.gax.httpjson.HttpJsonStubCallableFactory
-
Creates a callable object that represents a long-running operation.
- createOperationCallable(OperationCallSettings<RequestT, ResponseT, MetadataT>, ClientContext, LongRunningClient, UnaryCallable<RequestT, OperationSnapshot>) - Static method in class com.google.api.gax.httpjson.HttpJsonCallableFactory
- createPage(PageContext<ListOperationsRequest, ListOperationsResponse, Operation>, ListOperationsResponse) - Method in class com.google.api.gax.httpjson.longrunning.OperationsClient.ListOperationsPage
- createPage(PageContext<ListOperationsRequest, ListOperationsResponse, Operation>, ListOperationsResponse) - Method in class com.google.longrunning.OperationsClient.ListOperationsPage
- createPage(PageContext<RequestT, ResponseT, ResourceT>, ResponseT) - Method in class com.google.api.gax.paging.AbstractPage
- createPageAsync(PageContext<ListOperationsRequest, ListOperationsResponse, Operation>, ApiFuture<ListOperationsResponse>) - Method in class com.google.api.gax.httpjson.longrunning.OperationsClient.ListOperationsPage
- createPageAsync(PageContext<ListOperationsRequest, ListOperationsResponse, Operation>, ApiFuture<ListOperationsResponse>) - Method in class com.google.longrunning.OperationsClient.ListOperationsPage
- createPageAsync(PageContext<RequestT, ResponseT, ResourceT>, ApiFuture<ResponseT>) - Method in class com.google.api.gax.paging.AbstractPage
- createPagedCallable(GrpcCallSettings<RequestT, ResponseT>, PagedCallSettings<RequestT, ResponseT, PagedListResponseT>, ClientContext) - Static method in class com.google.api.gax.grpc.GrpcCallableFactory
-
Create a paged callable object that represents a paged API method.
- createPagedCallable(GrpcCallSettings<RequestT, ResponseT>, PagedCallSettings<RequestT, ResponseT, PagedListResponseT>, ClientContext) - Method in interface com.google.api.gax.grpc.GrpcStubCallableFactory
-
Create a paged callable object that represents a paged API method.
- createPagedCallable(GrpcCallSettings<RequestT, ResponseT>, PagedCallSettings<RequestT, ResponseT, PagedListResponseT>, ClientContext) - Method in class com.google.longrunning.stub.GrpcOperationsCallableFactory
- createPagedCallable(HttpJsonCallSettings<RequestT, ResponseT>, PagedCallSettings<RequestT, ResponseT, PagedListResponseT>, ClientContext) - Static method in class com.google.api.gax.httpjson.HttpJsonCallableFactory
-
Create a paged callable object that represents a paged API method.
- createPagedCallable(HttpJsonCallSettings<RequestT, ResponseT>, PagedCallSettings<RequestT, ResponseT, PagedListResponseT>, ClientContext) - Method in interface com.google.api.gax.httpjson.HttpJsonStubCallableFactory
-
Create a paged callable object that represents a paged API method.
- createPagedCallable(HttpJsonCallSettings<RequestT, ResponseT>, PagedCallSettings<RequestT, ResponseT, PagedListResponseT>, ClientContext) - Method in class com.google.api.gax.httpjson.longrunning.stub.HttpJsonOperationsCallableFactory
- createServerStreamingCallable(GrpcCallSettings<RequestT, ResponseT>, ServerStreamingCallSettings<RequestT, ResponseT>, ClientContext) - Static method in class com.google.api.gax.grpc.GrpcCallableFactory
-
Create a server-streaming callable with grpc-specific functionality.
- createServerStreamingCallable(GrpcCallSettings<RequestT, ResponseT>, ServerStreamingCallSettings<RequestT, ResponseT>, ClientContext) - Method in interface com.google.api.gax.grpc.GrpcStubCallableFactory
-
Create a server-streaming callable with grpc-specific functionality.
- createServerStreamingCallable(GrpcCallSettings<RequestT, ResponseT>, ServerStreamingCallSettings<RequestT, ResponseT>, ClientContext) - Method in class com.google.longrunning.stub.GrpcOperationsCallableFactory
- createServerStreamingCallable(GrpcCallSettings<RequestT, ResponseT>, StreamingCallSettings<RequestT, ResponseT>, ClientContext) - Static method in class com.google.api.gax.grpc.GrpcCallableFactory
-
Deprecated.Please use ServerStreamingCallSettings
- createServerStreamingCallable(GrpcCallSettings<RequestT, ResponseT>, Set<StatusCode.Code>) - Static method in class com.google.api.gax.grpc.GrpcRawCallableFactory
-
Create a server-streaming callable with grpc-specific functionality.
- createServerStreamingCallable(HttpJsonCallSettings<RequestT, ResponseT>, ServerStreamingCallSettings<RequestT, ResponseT>, ClientContext) - Static method in class com.google.api.gax.httpjson.HttpJsonCallableFactory
- createServerStreamingCallable(HttpJsonCallSettings<RequestT, ResponseT>, ServerStreamingCallSettings<RequestT, ResponseT>, ClientContext) - Method in interface com.google.api.gax.httpjson.HttpJsonStubCallableFactory
-
Create a server-streaming callable with.
- createSingleChannel() - Method in interface com.google.api.gax.grpc.ChannelFactory
- createStub() - Method in class com.google.api.gax.httpjson.longrunning.stub.OperationsStubSettings
- createStub() - Method in class com.google.longrunning.stub.OperationsStubSettings
- createUnaryCallable(GrpcCallSettings<RequestT, ResponseT>, UnaryCallSettings<RequestT, ResponseT>, ClientContext) - Static method in class com.google.api.gax.grpc.GrpcCallableFactory
-
Create a callable object with grpc-specific functionality.
- createUnaryCallable(GrpcCallSettings<RequestT, ResponseT>, UnaryCallSettings<RequestT, ResponseT>, ClientContext) - Method in interface com.google.api.gax.grpc.GrpcStubCallableFactory
-
Create a callable object with grpc-specific functionality.
- createUnaryCallable(GrpcCallSettings<RequestT, ResponseT>, UnaryCallSettings<RequestT, ResponseT>, ClientContext) - Method in class com.google.longrunning.stub.GrpcOperationsCallableFactory
- createUnaryCallable(GrpcCallSettings<RequestT, ResponseT>, Set<StatusCode.Code>) - Static method in class com.google.api.gax.grpc.GrpcRawCallableFactory
-
Create a Unary callable object with minimal grpc-specific functionality.
- createUnaryCallable(HttpJsonCallSettings<RequestT, ResponseT>, UnaryCallSettings<RequestT, ResponseT>, ClientContext) - Static method in class com.google.api.gax.httpjson.HttpJsonCallableFactory
-
Create a callable object with http/json-specific functionality.
- createUnaryCallable(HttpJsonCallSettings<RequestT, ResponseT>, UnaryCallSettings<RequestT, ResponseT>, ClientContext) - Method in interface com.google.api.gax.httpjson.HttpJsonStubCallableFactory
-
Create a callable object with http/json-specific functionality.
- createUnaryCallable(HttpJsonCallSettings<RequestT, ResponseT>, UnaryCallSettings<RequestT, ResponseT>, ClientContext) - Method in class com.google.api.gax.httpjson.longrunning.stub.HttpJsonOperationsCallableFactory
- CredentialsProvider - Interface in com.google.api.gax.core
-
Provides an interface to hold and acquire the credentials that will be used to call the service.
D
- DATA_LOSS - com.google.api.gax.rpc.StatusCode.Code
- DataLossException - Exception in com.google.api.gax.rpc
-
Exception thrown due to unrecoverable data loss or corruption.
- DataLossException(String, Throwable, StatusCode, boolean) - Constructor for exception com.google.api.gax.rpc.DataLossException
- DataLossException(Throwable, StatusCode, boolean) - Constructor for exception com.google.api.gax.rpc.DataLossException
- DataLossException(Throwable, StatusCode, boolean, ErrorDetails) - Constructor for exception com.google.api.gax.rpc.DataLossException
- DEADLINE_EXCEEDED - com.google.api.gax.rpc.StatusCode.Code
- DeadlineExceededException - Exception in com.google.api.gax.rpc
-
Exception thrown when deadline expired before operation could complete.
- DeadlineExceededException(String, Throwable, StatusCode, boolean) - Constructor for exception com.google.api.gax.rpc.DeadlineExceededException
- DeadlineExceededException(Throwable, StatusCode, boolean) - Constructor for exception com.google.api.gax.rpc.DeadlineExceededException
- DeadlineExceededException(Throwable, StatusCode, boolean, ErrorDetails) - Constructor for exception com.google.api.gax.rpc.DeadlineExceededException
- decreaseThresholds(long, long) - Method in class com.google.api.gax.batching.FlowController
-
Decrease flow control limits to allow elementSteps fewer elements and byteSteps fewer request bytes before enforcing flow control.
- DEFAULT - Static variable in class com.google.api.gax.httpjson.HttpJsonCallOptions
- defaultApiClientHeaderProviderBuilder() - Static method in class com.google.api.gax.httpjson.longrunning.OperationsSettings
- defaultApiClientHeaderProviderBuilder() - Static method in class com.google.api.gax.httpjson.longrunning.stub.OperationsStubSettings
- defaultApiClientHeaderProviderBuilder() - Static method in class com.google.longrunning.OperationsSettings
- defaultApiClientHeaderProviderBuilder() - Static method in class com.google.longrunning.stub.OperationsStubSettings
- defaultCredentialsProviderBuilder() - Static method in class com.google.api.gax.httpjson.longrunning.OperationsSettings
-
Returns a builder for the default credentials for this service.
- defaultCredentialsProviderBuilder() - Static method in class com.google.api.gax.httpjson.longrunning.stub.OperationsStubSettings
-
Returns a builder for the default credentials for this service.
- defaultCredentialsProviderBuilder() - Static method in class com.google.longrunning.OperationsSettings
-
Returns a builder for the default credentials for this service.
- defaultCredentialsProviderBuilder() - Static method in class com.google.longrunning.stub.OperationsStubSettings
-
Returns a builder for the default credentials for this service.
- defaultExecutorProviderBuilder() - Static method in class com.google.api.gax.httpjson.longrunning.OperationsSettings
-
Returns a builder for the default ExecutorProvider for this service.
- defaultExecutorProviderBuilder() - Static method in class com.google.api.gax.httpjson.longrunning.stub.OperationsStubSettings
-
Returns a builder for the default ExecutorProvider for this service.
- defaultExecutorProviderBuilder() - Static method in class com.google.longrunning.OperationsSettings
-
Returns a builder for the default ExecutorProvider for this service.
- defaultExecutorProviderBuilder() - Static method in class com.google.longrunning.stub.OperationsStubSettings
-
Returns a builder for the default ExecutorProvider for this service.
- defaultHttpJsonTransportProviderBuilder() - Static method in class com.google.api.gax.httpjson.longrunning.OperationsSettings
-
Returns a builder for the default ChannelProvider for this service.
- defaultHttpJsonTransportProviderBuilder() - Static method in class com.google.api.gax.httpjson.longrunning.stub.OperationsStubSettings
-
Returns a builder for the default ChannelProvider for this service.
- defaultTransportChannelProvider() - Static method in class com.google.api.gax.httpjson.longrunning.OperationsSettings
- defaultTransportChannelProvider() - Static method in class com.google.api.gax.httpjson.longrunning.stub.OperationsStubSettings
- delegate() - Method in class com.google.api.gax.httpjson.ForwardingHttpJsonClientCall
- delegate() - Method in class com.google.api.gax.httpjson.ForwardingHttpJsonClientCall.SimpleForwardingHttpJsonClientCall
- delegate() - Method in class com.google.api.gax.httpjson.ForwardingHttpJsonClientCallListener
- delegate() - Method in class com.google.api.gax.httpjson.ForwardingHttpJsonClientCallListener.SimpleForwardingHttpJsonClientCallListener
- deleteOperation(DeleteOperationRequest) - Method in class com.google.api.gax.httpjson.longrunning.OperationsClient
-
Deletes a long-running operation.
- deleteOperation(String) - Method in class com.google.api.gax.httpjson.longrunning.OperationsClient
-
Deletes a long-running operation.
- deleteOperation(String) - Method in class com.google.longrunning.OperationsClient
-
Deletes a long-running operation.
- deleteOperationCallable() - Method in class com.google.api.gax.httpjson.HttpJsonLongRunningClient
-
Returns a
UnaryCallable
which can issue calls to delete an operation. - deleteOperationCallable() - Method in class com.google.api.gax.httpjson.longrunning.OperationsClient
-
Deletes a long-running operation.
- deleteOperationCallable() - Method in class com.google.api.gax.httpjson.longrunning.stub.HttpJsonOperationsStub
- deleteOperationCallable() - Method in class com.google.api.gax.httpjson.longrunning.stub.OperationsStub
- deleteOperationCallable() - Method in interface com.google.api.gax.rpc.LongRunningClient
-
Returns a
UnaryCallable
which can issue calls to delete an operation. - deleteOperationCallable() - Method in class com.google.longrunning.OperationsClient
-
Deletes a long-running operation.
- deleteOperationCallable() - Method in class com.google.longrunning.stub.GrpcOperationsStub
- deleteOperationCallable() - Method in class com.google.longrunning.stub.OperationsStub
- deleteOperationSettings() - Method in class com.google.api.gax.httpjson.longrunning.OperationsSettings.Builder
-
Returns the builder for the settings used for calls to delete.
- deleteOperationSettings() - Method in class com.google.api.gax.httpjson.longrunning.OperationsSettings
-
Returns the object with the settings used for calls to delete.
- deleteOperationSettings() - Method in class com.google.api.gax.httpjson.longrunning.stub.OperationsStubSettings.Builder
-
Returns the builder for the settings used for calls to delete.
- deleteOperationSettings() - Method in class com.google.api.gax.httpjson.longrunning.stub.OperationsStubSettings
-
Returns the object with the settings used for calls to delete.
- deleteOperationSettings() - Method in class com.google.longrunning.OperationsSettings.Builder
-
Returns the builder for the settings used for calls to deleteOperation.
- deleteOperationSettings() - Method in class com.google.longrunning.OperationsSettings
-
Returns the object with the settings used for calls to deleteOperation.
- deleteOperationSettings() - Method in class com.google.longrunning.stub.OperationsStubSettings.Builder
-
Returns the builder for the settings used for calls to deleteOperation.
- deleteOperationSettings() - Method in class com.google.longrunning.stub.OperationsStubSettings
-
Returns the object with the settings used for calls to deleteOperation.
- DirectRetryingExecutor<ResponseT> - Class in com.google.api.gax.retrying
-
The retry executor which executes attempts in the current thread, potentially causing the current thread to sleep for the specified amount of time before execution.
- DirectRetryingExecutor(RetryAlgorithm<ResponseT>) - Constructor for class com.google.api.gax.retrying.DirectRetryingExecutor
-
Creates a new direct retrying executor instance, which will be using
retryAlgorithm
to determine retrying strategy. - disableAutoInboundFlowControl() - Method in interface com.google.api.gax.rpc.StreamController
-
Disables automatic flow control.
- Distribution - Class in com.google.api.gax.core
-
Distribution records values from
0
(inclusive) toendValue
(exclusive) and computes their percentiles. - Distribution(int) - Constructor for class com.google.api.gax.core.Distribution
- DynamicFlowControlSettings - Class in com.google.api.gax.batching
-
Settings for dynamic flow control
- DynamicFlowControlSettings() - Constructor for class com.google.api.gax.batching.DynamicFlowControlSettings
- DynamicFlowControlSettings.Builder - Class in com.google.api.gax.batching
E
- ElementCounter<E> - Interface in com.google.api.gax.batching
-
Interface representing an object that provides a numerical count given an object of the parameterized type.
- empty() - Static method in class com.google.api.gax.paging.Pages
-
Returns a page that contains nothing.
- emptyToken() - Method in interface com.google.api.gax.rpc.PagedListDescriptor
-
Delivers the empty page token.
- encode(RequestT) - Method in interface com.google.api.gax.rpc.RequestParamsEncoder
-
Encodes
request
message in a string. - encode(RequestT) - Method in class com.google.api.gax.rpc.RequestUrlParamsEncoder
-
Encodes the
request
in a form of a URL parameters string, for example"param1=value+1¶m2=value2%26"
. - enhance(HttpHeaders) - Method in interface com.google.api.gax.httpjson.HttpJsonHeaderEnhancer
- EnvironmentProvider - Interface in com.google.api.gax.rpc.internal
-
Provides an interface to provide the environment variable values.
- equals(Object) - Method in class com.google.api.gax.batching.PartitionKey
- equals(Object) - Method in class com.google.api.gax.grpc.GrpcCallContext
- equals(Object) - Method in class com.google.api.gax.httpjson.HttpJsonCallContext
- equals(Object) - Method in class com.google.api.gax.httpjson.HttpJsonStatusCode
- equals(Object) - Method in class com.google.api.gax.rpc.UnaryCallSettings
- equals(Object) - Method in class com.google.api.gax.tracing.OpencensusTracerFactory
- ErrorDetails - Class in com.google.api.gax.rpc
-
This class contains a list of standard error messages that returns from server.
- ErrorDetails() - Constructor for class com.google.api.gax.rpc.ErrorDetails
- ErrorDetails.Builder - Class in com.google.api.gax.rpc
- ExecutorAsBackgroundResource - Class in com.google.api.gax.core
-
ExecutorAsBackgroundResource wraps an
ExecutorService
so that it can be used as aBackgroundResource
. - ExecutorAsBackgroundResource(ExecutorService) - Constructor for class com.google.api.gax.core.ExecutorAsBackgroundResource
- ExecutorProvider - Interface in com.google.api.gax.core
-
Provides an interface to either build a ScheduledExecutorService or provide a fixed ScheduledExecutorService that will be used to make calls to a service.
- expandToFixedSizeCollection(int) - Method in class com.google.api.gax.paging.AbstractPagedListResponse
- expandToFixedSizeCollection(int) - Method in interface com.google.api.gax.paging.PagedListResponse
-
Returns a collection of elements with a fixed size set by the collectionSize parameter.
- ExponentialPollAlgorithm - Class in com.google.api.gax.retrying
-
The timed poll algorithm which uses jittered exponential backoff factor for calculating the next poll execution time and throws
PollException
in case if total timeout or total number of attempts is reached. - ExponentialPollAlgorithm(RetrySettings, ApiClock) - Constructor for class com.google.api.gax.retrying.ExponentialPollAlgorithm
-
Creates a new exponential poll algorithm instance.
- ExponentialRetryAlgorithm - Class in com.google.api.gax.retrying
-
The timed retry algorithm which uses jittered exponential backoff factor for calculating the next attempt execution time.
- ExponentialRetryAlgorithm(RetrySettings, ApiClock) - Constructor for class com.google.api.gax.retrying.ExponentialRetryAlgorithm
-
Creates a new exponential retry algorithm instance.
- extract(RequestT) - Method in interface com.google.api.gax.httpjson.FieldsExtractor
- extract(RequestT) - Method in interface com.google.api.gax.rpc.RequestParamsExtractor
-
Extracts specific fields from the
request
and returns them in a form of key-value pairs, where a key is a field name and a value is a field's string representation. - extractNextToken(ResponseT) - Method in interface com.google.api.gax.rpc.PagedListDescriptor
-
Extracts the next token from the response.
- extractPageSize(RequestT) - Method in interface com.google.api.gax.rpc.PagedListDescriptor
-
Extracts the page size setting from the request.
- extractResources(ResponseT) - Method in interface com.google.api.gax.rpc.PagedListDescriptor
-
Extracts an iterable of resources from the response.
F
- FAILED_PRECONDITION - com.google.api.gax.rpc.StatusCode.Code
- FailedPreconditionException - Exception in com.google.api.gax.rpc
-
Exception thrown when the operation was rejected because the system is not in a state required for the operation's execution.
- FailedPreconditionException(String, Throwable, StatusCode, boolean) - Constructor for exception com.google.api.gax.rpc.FailedPreconditionException
- FailedPreconditionException(Throwable, StatusCode, boolean) - Constructor for exception com.google.api.gax.rpc.FailedPreconditionException
- FailedPreconditionException(Throwable, StatusCode, boolean, ErrorDetails) - Constructor for exception com.google.api.gax.rpc.FailedPreconditionException
- FieldsExtractor<RequestT,ParamsT> - Interface in com.google.api.gax.httpjson
-
A functional interface to be implemented for each request message to extract specific fields from it.
- first() - Method in class com.google.api.gax.rpc.ServerStreamingCallable
-
Construct a
UnaryCallable
that will yield the first item in the stream and cancel it. - FixedCredentialsProvider - Class in com.google.api.gax.core
-
FixedCredentialsProvider is a CredentialsProvider which always provides the same credentials.
- FixedCredentialsProvider() - Constructor for class com.google.api.gax.core.FixedCredentialsProvider
- FixedExecutorProvider - Class in com.google.api.gax.core
-
FixedExecutorProvider is an ExecutorProvider which always returns the same executor.
- FixedHeaderProvider - Class in com.google.api.gax.rpc
-
An instance of HeaderProvider that always provides the same headers.
- FixedHeaderProvider() - Constructor for class com.google.api.gax.rpc.FixedHeaderProvider
- FixedSizeCollection<ResourceT> - Interface in com.google.api.gax.paging
-
A FixedSizeCollection object wraps multiple API list method responses into a single collection with a fixed number of elements.
- FixedTransportChannelProvider - Class in com.google.api.gax.rpc
-
An instance of TransportChannelProvider that always provides the same TransportChannel.
- FixedWatchdogProvider - Class in com.google.api.gax.rpc
-
A watchdog provider which always returns the same watchdog instance provided to the provider during construction.
- FlowControlEventStats - Class in com.google.api.gax.batching
-
Record the statistics of flow control events.
- FlowControlEventStats() - Constructor for class com.google.api.gax.batching.FlowControlEventStats
- FlowControlEventStats.FlowControlEvent - Class in com.google.api.gax.batching
-
A flow control event.
- FlowController - Class in com.google.api.gax.batching
-
Provides flow control capability.
- FlowController(DynamicFlowControlSettings) - Constructor for class com.google.api.gax.batching.FlowController
- FlowController(FlowControlSettings) - Constructor for class com.google.api.gax.batching.FlowController
- FlowController.FlowControlException - Exception in com.google.api.gax.batching
-
Base exception that signals a flow control state.
- FlowController.FlowControlRuntimeException - Exception in com.google.api.gax.batching
-
Runtime exception that can be used in place of FlowControlException when an unchecked exception is required.
- FlowController.LimitExceededBehavior - Enum in com.google.api.gax.batching
-
Enumeration of behaviors that FlowController can use in case the flow control limits are exceeded.
- FlowController.MaxOutstandingElementCountReachedException - Exception in com.google.api.gax.batching
-
Exception thrown when client-side flow control is enforced based on the maximum number of outstanding in-memory elements.
- FlowController.MaxOutstandingRequestBytesReachedException - Exception in com.google.api.gax.batching
-
Exception thrown when client-side flow control is enforced based on the maximum number of unacknowledged in-memory bytes.
- FlowControlSettings - Class in com.google.api.gax.batching
-
Settings for
FlowController
. - FlowControlSettings() - Constructor for class com.google.api.gax.batching.FlowControlSettings
- FlowControlSettings.Builder - Class in com.google.api.gax.batching
- flush() - Method in interface com.google.api.gax.batching.Batcher
-
Synchronously sends any pending elements as a batch and waits for all outstanding batches to be complete.
- flush() - Method in class com.google.api.gax.batching.BatcherImpl
-
Synchronously sends any pending elements as a batch and waits for all outstanding batches to be complete.
- ForwardingHttpJsonClientCall<RequestT,ResponseT> - Class in com.google.api.gax.httpjson
-
A
HttpJsonClientCall
which forwards all of its methods to anotherHttpJsonClientCall
. - ForwardingHttpJsonClientCall() - Constructor for class com.google.api.gax.httpjson.ForwardingHttpJsonClientCall
- ForwardingHttpJsonClientCall.SimpleForwardingHttpJsonClientCall<RequestT,ResponseT> - Class in com.google.api.gax.httpjson
-
A simplified version of
ForwardingHttpJsonClientCall
where subclasses can pass in aHttpJsonClientCall
as the delegate. - ForwardingHttpJsonClientCallListener<ResponseT> - Class in com.google.api.gax.httpjson
-
A
HttpJsonClientCall.Listener
which forwards all of its methods to anotherHttpJsonClientCall.Listener
. - ForwardingHttpJsonClientCallListener() - Constructor for class com.google.api.gax.httpjson.ForwardingHttpJsonClientCallListener
- ForwardingHttpJsonClientCallListener.SimpleForwardingHttpJsonClientCallListener<ResponseT> - Class in com.google.api.gax.httpjson
-
A simplified version of
ForwardingHttpJsonClientCallListener
where subclasses can pass in aHttpJsonClientCall.Listener
as the delegate. - fromFlowControlException(FlowController.FlowControlException) - Static method in exception com.google.api.gax.batching.FlowController.FlowControlRuntimeException
- futureCall(OuterRequestT, ApiCallContext) - Method in class com.google.api.gax.rpc.TranslatingUnaryCallable
- futureCall(RequestT) - Method in class com.google.api.gax.rpc.OperationCallable
-
Same as
OperationCallable.futureCall(Object, ApiCallContext)
, with a null context. - futureCall(RequestT) - Method in class com.google.api.gax.rpc.UnaryCallable
-
Same as
UnaryCallable.futureCall(Object, ApiCallContext)
, with a null context. - futureCall(RequestT, ApiCallContext) - Method in class com.google.api.gax.httpjson.HttpJsonOperationSnapshotCallable
-
Perform a call asynchronously.
- futureCall(RequestT, ApiCallContext) - Method in class com.google.api.gax.rpc.BatchingCallable
- futureCall(RequestT, ApiCallContext) - Method in class com.google.api.gax.rpc.OperationCallable
-
Initiates an operation asynchronously.
- futureCall(RequestT, ApiCallContext) - Method in class com.google.api.gax.rpc.PagedCallable
- futureCall(RequestT, ApiCallContext) - Method in class com.google.api.gax.rpc.UnaryCallable
-
Perform a call asynchronously.
- futureCall(RequestT, ApiCallContext) - Method in class com.google.api.gax.tracing.TracedBatchingCallable
- futureCall(RequestT, ApiCallContext) - Method in class com.google.api.gax.tracing.TracedOperationCallable
-
Wrap the initial start polling logical operations in a single parent trace using a
ApiTracerFactory.OperationType.LongRunning
ApiTracer
. - futureCall(RequestT, ApiCallContext) - Method in class com.google.api.gax.tracing.TracedOperationInitialCallable
- futureCall(RequestT, ApiCallContext) - Method in class com.google.api.gax.tracing.TracedUnaryCallable
-
Calls the wrapped
UnaryCallable
within the context of a new trace.
G
- GaxGrpcProperties - Class in com.google.api.gax.grpc
-
Provides properties of the GAX-GRPC library.
- GaxHttpJsonProperties - Class in com.google.api.gax.httpjson
-
Provides properties of the GAX-HTTPJSON library.
- GaxHttpJsonProperties() - Constructor for class com.google.api.gax.httpjson.GaxHttpJsonProperties
- GaxProperties - Class in com.google.api.gax.core
-
Provides properties of the GAX library.
- get() - Method in class com.google.api.gax.longrunning.OperationFutureImpl
- get(long, TimeUnit) - Method in class com.google.api.gax.longrunning.OperationFutureImpl
- getAdditionalPathTemplates() - Method in interface com.google.api.gax.httpjson.HttpRequestFormatter
-
Additional (alternative) path templates for endpoint URL path.
- getAdditionalPathTemplates() - Method in class com.google.api.gax.httpjson.ProtoMessageRequestFormatter
- getApiClientHeaderKey() - Method in class com.google.api.gax.rpc.ApiClientHeaderProvider.Builder
- getAttemptCount() - Method in class com.google.api.gax.retrying.TimedAttemptSettings
-
The attempt count.
- getAttemptResult() - Method in interface com.google.api.gax.retrying.RetryingFuture
-
Returns the current (active on the moment of the execution of this method) attempt result future, allowing to track progress of the retrying future execution.
- getAttemptSettings() - Method in interface com.google.api.gax.retrying.RetryingFuture
-
Returns current (active) attempt settings.
- getAuthenticationType() - Method in class com.google.api.gax.rpc.internal.QuotaProjectIdHidingCredentials
- getBackgroundExecutorProvider() - Method in class com.google.api.gax.rpc.ClientSettings.Builder
-
Gets the ExecutorProvider that was previously set on this Builder.
- getBackgroundExecutorProvider() - Method in class com.google.api.gax.rpc.ClientSettings
- getBackgroundExecutorProvider() - Method in class com.google.api.gax.rpc.StubSettings.Builder
-
Gets the ExecutorProvider that was previously set on this Builder.
- getBackgroundExecutorProvider() - Method in class com.google.api.gax.rpc.StubSettings
- getBackgroundResources() - Method in class com.google.api.gax.rpc.ClientContext
-
The objects that need to be closed in order to clean up the resources created in the process of creating this ClientContext.
- getBadRequest() - Method in class com.google.api.gax.rpc.ErrorDetails
-
Describes violations in a client request.
- getBatches() - Method in class com.google.api.gax.batching.AccumulatingBatchReceiver
-
Returns the accumulated batches.
- getBatchingDescriptor() - Method in class com.google.api.gax.batching.BatchingCallSettings
- getBatchingDescriptor() - Method in class com.google.api.gax.rpc.BatchingCallSettings.Builder
- getBatchingDescriptor() - Method in class com.google.api.gax.rpc.BatchingCallSettings
- getBatchingSettings() - Method in class com.google.api.gax.batching.BatchingCallSettings.Builder
-
Returns the
BatchingSettings
. - getBatchingSettings() - Method in class com.google.api.gax.batching.BatchingCallSettings
-
Returns batching settings which contains multiple batch threshold levels.
- getBatchingSettings() - Method in class com.google.api.gax.rpc.BatcherFactory
-
Returns the BatchingSettings object that is associated with this factory.
- getBatchingSettings() - Method in class com.google.api.gax.rpc.BatchingCallSettings.Builder
- getBatchingSettings() - Method in class com.google.api.gax.rpc.BatchingCallSettings
- getBatchPartitionKey(RequestT) - Method in interface com.google.api.gax.rpc.BatchingDescriptor
-
Returns the value of the partition key for the given request.
- getByteCount() - Method in class com.google.api.gax.rpc.Batch
- getCallable() - Method in interface com.google.api.gax.retrying.RetryingFuture
-
Returns callable tracked by this future.
- getCallable() - Method in class com.google.api.gax.rpc.Batch
- getCallable() - Method in class com.google.api.gax.rpc.PageContext
- getCallContext() - Method in class com.google.api.gax.rpc.PageContext
- getCallOptions() - Method in class com.google.api.gax.grpc.GrpcCallContext
-
The
CallOptions
set on this context. - getCallOptions() - Method in class com.google.api.gax.httpjson.HttpJsonCallContext
- getChannel() - Method in class com.google.api.gax.grpc.GrpcCallContext
-
The
Channel
set on this context. - getChannel() - Method in class com.google.api.gax.grpc.GrpcTransportChannel
- getChannel() - Method in class com.google.api.gax.httpjson.HttpJsonCallContext
- getChannel() - Method in class com.google.api.gax.httpjson.HttpJsonTransportChannel
-
The channel in use.
- getChannelAffinity() - Method in class com.google.api.gax.grpc.GrpcCallContext
-
The channel affinity for this context.
- getChannelConfigurator() - Method in class com.google.api.gax.grpc.InstantiatingGrpcChannelProvider.Builder
- getClientLibToken() - Method in class com.google.api.gax.rpc.ApiClientHeaderProvider.Builder
- getClientName() - Method in class com.google.api.gax.tracing.SpanName
-
The name of the client.
- getClock() - Method in class com.google.api.gax.rpc.ClientContext
- getClock() - Method in class com.google.api.gax.rpc.ClientSettings.Builder
-
Gets the ApiClock that was previously set on this Builder.
- getClock() - Method in class com.google.api.gax.rpc.ClientSettings
- getClock() - Method in class com.google.api.gax.rpc.StubSettings.Builder
-
Gets the ApiClock that was previously set on this Builder.
- getClock() - Method in class com.google.api.gax.rpc.StubSettings
- getCode() - Method in class com.google.api.gax.grpc.GrpcStatusCode
-
Returns the
Status.Code
from grpc. - getCode() - Method in class com.google.api.gax.httpjson.HttpJsonStatusCode
- getCode() - Method in interface com.google.api.gax.rpc.StatusCode
-
Return the code enum value.
- getCollectionSize() - Method in class com.google.api.gax.paging.AbstractFixedSizeCollection
- getCollectionSize() - Method in interface com.google.api.gax.paging.FixedSizeCollection
-
Returns the number of elements in the collection.
- getCommands() - Method in class com.google.api.gax.rpc.mtls.ContextAwareMetadataJson
-
Returns the cert provider command.
- getCredentials() - Method in interface com.google.api.gax.core.CredentialsProvider
-
Gets the credentials which will be used to call the service.
- getCredentials() - Method in class com.google.api.gax.core.FixedCredentialsProvider
- getCredentials() - Method in class com.google.api.gax.core.GoogleCredentialsProvider
- getCredentials() - Method in class com.google.api.gax.core.NoCredentialsProvider
- getCredentials() - Method in class com.google.api.gax.httpjson.HttpJsonCallContext
-
Deprecated.
- getCredentials() - Method in class com.google.api.gax.httpjson.HttpJsonCallOptions
- getCredentials() - Method in class com.google.api.gax.rpc.ClientContext
- getCredentialsProvider() - Method in class com.google.api.gax.rpc.ClientSettings.Builder
-
Gets the CredentialsProvider that was previously set on this Builder.
- getCredentialsProvider() - Method in class com.google.api.gax.rpc.ClientSettings
- getCredentialsProvider() - Method in class com.google.api.gax.rpc.StubSettings.Builder
-
Gets the CredentialsProvider that was previously set on this Builder.
- getCredentialsProvider() - Method in class com.google.api.gax.rpc.StubSettings
- getCurrentElementCountLimit() - Method in class com.google.api.gax.batching.FlowController
- getCurrentMaxBatchBytes() - Method in exception com.google.api.gax.batching.FlowController.MaxOutstandingRequestBytesReachedException
- getCurrentMaxBatchElementCount() - Method in exception com.google.api.gax.batching.FlowController.MaxOutstandingElementCountReachedException
- getCurrentRequestBytesLimit() - Method in class com.google.api.gax.batching.FlowController
- getDeadline() - Method in class com.google.api.gax.httpjson.HttpJsonCallContext
-
Deprecated.
- getDeadline() - Method in class com.google.api.gax.httpjson.HttpJsonCallOptions
- getDebugInfo() - Method in class com.google.api.gax.rpc.ErrorDetails
-
Describes additional debugging info.
- getDefaultApiClientHeaderKey() - Static method in class com.google.api.gax.rpc.ApiClientHeaderProvider
- getDefaultApiClientHeaderPattern() - Static method in class com.google.api.gax.grpc.GaxGrpcProperties
-
Returns default api client header pattern (to facilitate testing)
- getDefaultApiClientHeaderPattern() - Static method in class com.google.api.gax.httpjson.GaxHttpJsonProperties
-
Returns default api client header pattern (to facilitate testing)
- getDefaultCallContext() - Method in class com.google.api.gax.rpc.ClientContext
- getDefaultEndpoint() - Static method in class com.google.api.gax.httpjson.longrunning.OperationsSettings
-
Returns the default service endpoint.
- getDefaultEndpoint() - Static method in class com.google.api.gax.httpjson.longrunning.stub.OperationsStubSettings
-
Returns the default service endpoint.
- getDefaultInstance() - Static method in class com.google.api.gax.batching.FlowControlSettings
- getDefaultMtlsEndpoint() - Static method in class com.google.api.gax.httpjson.longrunning.stub.OperationsStubSettings
-
Returns the default mTLS service endpoint.
- getDefaultOptions() - Static method in class com.google.api.gax.rpc.internal.ApiCallContextOptions
- getDefaultResourceHeaderKey() - Static method in class com.google.api.gax.rpc.ApiClientHeaderProvider
- getDefaultServiceScopes() - Static method in class com.google.api.gax.httpjson.longrunning.OperationsSettings
-
Returns the default service scopes.
- getDefaultServiceScopes() - Static method in class com.google.api.gax.httpjson.longrunning.stub.OperationsStubSettings
-
Returns the default service scopes.
- getDelayThreshold() - Method in class com.google.api.gax.batching.BatchingSettings
-
Get the delay threshold to use for batching.
- getDomain() - Method in exception com.google.api.gax.rpc.ApiException
-
Returns the logical grouping to which the "reason" belongs.
- getElement() - Method in class com.google.api.gax.batching.BatchEntry
- getElementCountThreshold() - Method in class com.google.api.gax.batching.BatchingSettings
-
Get the element count threshold to use for batching.
- getEmptyCallContext() - Method in class com.google.api.gax.grpc.GrpcTransportChannel
- getEmptyCallContext() - Method in class com.google.api.gax.httpjson.HttpJsonTransportChannel
- getEmptyCallContext() - Method in interface com.google.api.gax.rpc.TransportChannel
-
Returns an empty
ApiCallContext
that is compatible with thisTransportChannel
. - getEndpoint() - Method in class com.google.api.gax.grpc.InstantiatingGrpcChannelProvider.Builder
- getEndpoint() - Method in class com.google.api.gax.grpc.InstantiatingGrpcChannelProvider
-
The endpoint to be used for the channel.
- getEndpoint() - Method in class com.google.api.gax.httpjson.InstantiatingHttpJsonChannelProvider.Builder
- getEndpoint() - Method in class com.google.api.gax.httpjson.InstantiatingHttpJsonChannelProvider
-
The endpoint to be used for the channel.
- getEndpoint() - Method in class com.google.api.gax.rpc.ClientContext
- getEndpoint() - Method in class com.google.api.gax.rpc.ClientSettings.Builder
- getEndpoint() - Method in class com.google.api.gax.rpc.ClientSettings
- getEndpoint() - Method in class com.google.api.gax.rpc.StubSettings.Builder
- getEndpoint() - Method in class com.google.api.gax.rpc.StubSettings
- getenv(String) - Method in interface com.google.api.gax.rpc.internal.EnvironmentProvider
-
Returns the environment variable value.
- getErrorCode() - Method in class com.google.api.gax.httpjson.HttpJsonOperationSnapshot
-
If the operation is done and it failed, returns the failure status code; if the operation is not done or if it succeeded, returns null.
- getErrorCode() - Method in interface com.google.api.gax.longrunning.OperationSnapshot
-
If the operation is done and it failed, returns the failure status code; if the operation is not done or if it succeeded, returns null.
- getErrorDetails() - Method in exception com.google.api.gax.rpc.ApiException
-
Returns all standard error messages that server sends.
- getErrorInfo() - Method in class com.google.api.gax.rpc.ErrorDetails
-
This is the most important and special error message.
- getErrorMessage() - Method in class com.google.api.gax.httpjson.HttpJsonOperationSnapshot
-
If the operation is done and it failed, returns the error message; if the operation is not done or if it succeeded, returns null.
- getErrorMessage() - Method in interface com.google.api.gax.longrunning.OperationSnapshot
-
If the operation is done and it failed, returns the error message; if the operation is not done or if it succeeded, returns null.
- getException() - Method in class com.google.api.gax.batching.FlowControlEventStats.FlowControlEvent
- getException() - Method in class com.google.api.gax.httpjson.HttpJsonMetadata
- getExecutor() - Method in interface com.google.api.gax.core.ExecutorProvider
-
Gets the executor to use.
- getExecutor() - Method in class com.google.api.gax.core.FixedExecutorProvider
- getExecutor() - Method in class com.google.api.gax.core.InstantiatingExecutorProvider
- getExecutor() - Method in class com.google.api.gax.rpc.ClientContext
-
Gets the executor to use for running scheduled API call logic (such as retries and long-running operations).
- getExecutorProvider() - Method in class com.google.api.gax.rpc.ClientSettings.Builder
-
Deprecated.Please use
ClientSettings.Builder.getBackgroundExecutorProvider()
for getting the executor provider that's used for running scheduled API call logic. - getExecutorProvider() - Method in class com.google.api.gax.rpc.ClientSettings
-
Deprecated.
- getExecutorProvider() - Method in class com.google.api.gax.rpc.StubSettings.Builder
-
Deprecated.
- getExecutorProvider() - Method in class com.google.api.gax.rpc.StubSettings
-
Deprecated.Please use
StubSettings.getBackgroundExecutorProvider()
. - getExecutorThreadCount() - Method in class com.google.api.gax.core.InstantiatingExecutorProvider.Builder
- getExecutorThreadCount() - Method in class com.google.api.gax.core.InstantiatingExecutorProvider
-
The number of threads used by the executor created by this ExecutorProvider.
- getExtraHeaders() - Method in class com.google.api.gax.grpc.GrpcCallContext
-
The extra header for this context.
- getExtraHeaders() - Method in class com.google.api.gax.httpjson.HttpJsonCallContext
- getExtraHeaders() - Method in interface com.google.api.gax.rpc.ApiCallContext
-
Return the extra headers set for this context.
- getFirstAttemptStartTimeNanos() - Method in class com.google.api.gax.retrying.TimedAttemptSettings
-
The start time of the first attempt.
- getFlowControlEventStats() - Method in class com.google.api.gax.batching.FlowController
- getFlowController() - Method in class com.google.api.gax.batching.BatcherImpl
- getFlowController() - Method in class com.google.api.gax.rpc.BatchingCallSettings.Builder
- getFlowController() - Method in class com.google.api.gax.rpc.BatchingCallSettings
- getFlowControlSettings() - Method in class com.google.api.gax.batching.BatchingSettings
-
Get the flow control settings to use.
- getFullMethodName() - Method in class com.google.api.gax.httpjson.ApiMethodDescriptor
- getFuturePagedResponse(UnaryCallable<RequestT, ResponseT>, RequestT, ApiCallContext, ApiFuture<ResponseT>) - Method in interface com.google.api.gax.rpc.PagedListResponseFactory
- getGaxGrpcVersion() - Static method in class com.google.api.gax.grpc.GaxGrpcProperties
- getGaxVersion() - Static method in class com.google.api.gax.core.GaxProperties
-
Returns the current version of GAX.
- getGeneratedLibToken() - Method in class com.google.api.gax.rpc.ApiClientHeaderProvider.Builder
- getGeneratedRuntimeToken() - Method in class com.google.api.gax.rpc.ApiClientHeaderProvider.Builder
- getGlobalSettings() - Method in class com.google.api.gax.retrying.TimedAttemptSettings
-
Returns global (attempt-independent) retry settings.
- getGrpcTokenName() - Static method in class com.google.api.gax.grpc.GaxGrpcProperties
- getGrpcTransportName() - Static method in class com.google.api.gax.grpc.GrpcTransportChannel
-
The name of the Grpc transport.
- getGrpcVersion() - Static method in class com.google.api.gax.grpc.GaxGrpcProperties
-
Returns the current version of gRPC
- getHeaderProvider() - Method in class com.google.api.gax.rpc.ClientSettings.Builder
-
Gets the custom HeaderProvider that was previously set on this Builder.
- getHeaderProvider() - Method in class com.google.api.gax.rpc.ClientSettings
- getHeaderProvider() - Method in class com.google.api.gax.rpc.StubSettings.Builder
-
Gets the custom HeaderProvider that was previously set on this Builder.
- getHeaderProvider() - Method in class com.google.api.gax.rpc.StubSettings
- getHeaders() - Method in class com.google.api.gax.httpjson.HttpJsonMetadata
- getHeaders() - Method in class com.google.api.gax.rpc.ApiClientHeaderProvider
- getHeaders() - Method in class com.google.api.gax.rpc.ClientContext
- getHeaders() - Method in class com.google.api.gax.rpc.FixedHeaderProvider
- getHeaders() - Method in interface com.google.api.gax.rpc.HeaderProvider
-
Get the headers to put on http requests.
- getHeaders() - Method in class com.google.api.gax.rpc.NoHeaderProvider
- getHelp() - Method in class com.google.api.gax.rpc.ErrorDetails
-
Provides links to documentation or for performing an out-of-band action.
- getHttpJsonTokenName() - Static method in class com.google.api.gax.httpjson.GaxHttpJsonProperties
- getHttpJsonTransportName() - Static method in class com.google.api.gax.httpjson.HttpJsonTransportChannel
-
The name of the Http-JSON transport.
- getHttpJsonVersion() - Static method in class com.google.api.gax.httpjson.GaxHttpJsonProperties
- getHttpMethod() - Method in class com.google.api.gax.httpjson.ApiMethodDescriptor
-
Return the HTTP method for this request message type.
- getHttpStatusCode() - Method in enum com.google.api.gax.rpc.StatusCode.Code
- getIdleTimeout() - Method in class com.google.api.gax.rpc.ServerStreamingCallSettings.Builder
- getIdleTimeout() - Method in class com.google.api.gax.rpc.ServerStreamingCallSettings
-
See the class documentation of
ServerStreamingCallSettings
for a description of what theServerStreamingCallSettings.idleTimeout
does. - getInitialCallSettings() - Method in class com.google.api.gax.rpc.OperationCallSettings.Builder
-
Get the call settings which are used on the call to initiate the operation.
- getInitialCallSettings() - Method in class com.google.api.gax.rpc.OperationCallSettings
- getInitialChannelCount() - Method in class com.google.api.gax.grpc.ChannelPoolSettings
-
The initial size of the channel pool.
- getInitialFuture() - Method in interface com.google.api.gax.longrunning.OperationFuture
-
Returns the
OperationSnapshot
future of the initial request which started thisOperationFuture
. - getInitialFuture() - Method in class com.google.api.gax.longrunning.OperationFutureImpl
- getInitialOutstandingElementCount() - Method in class com.google.api.gax.batching.DynamicFlowControlSettings
-
Number of outstanding elements that
FlowController
allows when it's initiated. - getInitialOutstandingRequestBytes() - Method in class com.google.api.gax.batching.DynamicFlowControlSettings
-
Number of outstanding bytes that
FlowController
allows when it's initiated. - getInitialRetryDelay() - Method in class com.google.api.gax.retrying.RetrySettings.Builder
-
InitialRetryDelay controls the delay before the first retry.
- getInitialRetryDelay() - Method in class com.google.api.gax.retrying.RetrySettings
-
InitialRetryDelay controls the delay before the first retry.
- getInitialRpcTimeout() - Method in class com.google.api.gax.retrying.RetrySettings.Builder
-
InitialRpcTimeout controls the timeout for the initial RPC.
- getInitialRpcTimeout() - Method in class com.google.api.gax.retrying.RetrySettings
-
InitialRpcTimeout controls the timeout for the initial RPC.
- getInstance() - Static method in class com.google.api.gax.tracing.BaseApiTracer
- getInstance() - Static method in class com.google.api.gax.tracing.BaseApiTracerFactory
- getInterceptors() - Method in interface com.google.api.gax.grpc.GrpcInterceptorProvider
-
Get the list of client interceptors.
- getInterceptors() - Method in interface com.google.api.gax.httpjson.HttpJsonInterceptorProvider
-
Get the list of client interceptors.
- getInternalHeaderProvider() - Method in class com.google.api.gax.rpc.ClientSettings.Builder
-
Gets the internal HeaderProvider that was previously set on this Builder.
- getInternalHeaderProvider() - Method in class com.google.api.gax.rpc.ClientSettings
- getInternalHeaderProvider() - Method in class com.google.api.gax.rpc.StubSettings.Builder
-
Gets the internal HeaderProvider that was previously set on this Builder.
- getInternalHeaderProvider() - Method in class com.google.api.gax.rpc.StubSettings
- getInternalHeaders() - Method in class com.google.api.gax.rpc.ClientContext
- getIsEnabled() - Method in class com.google.api.gax.batching.BatchingSettings
-
Returns the Boolean object to indicate if the batching is enabled.
- getJavaVersion() - Static method in class com.google.api.gax.core.GaxProperties
-
Returns the version of the running JVM
- getJvmToken() - Method in class com.google.api.gax.rpc.ApiClientHeaderProvider.Builder
- getJwtEnabledScopes() - Method in class com.google.api.gax.core.GoogleCredentialsProvider.Builder
-
The JWT enable scopes previously provided.
- getJwtEnabledScopes() - Method in class com.google.api.gax.core.GoogleCredentialsProvider
- getKeepAliveTime() - Method in class com.google.api.gax.grpc.InstantiatingGrpcChannelProvider.Builder
-
The time without read activity before sending a keepalive ping.
- getKeepAliveTime() - Method in class com.google.api.gax.grpc.InstantiatingGrpcChannelProvider
-
The time without read activity before sending a keepalive ping.
- getKeepAliveTimeout() - Method in class com.google.api.gax.grpc.InstantiatingGrpcChannelProvider.Builder
-
The time without read activity after sending a keepalive ping.
- getKeepAliveTimeout() - Method in class com.google.api.gax.grpc.InstantiatingGrpcChannelProvider
-
The time without read activity after sending a keepalive ping.
- getKeepAliveWithoutCalls() - Method in class com.google.api.gax.grpc.InstantiatingGrpcChannelProvider.Builder
-
Whether keepalive will be performed when there are no outstanding RPCs.
- getKeepAliveWithoutCalls() - Method in class com.google.api.gax.grpc.InstantiatingGrpcChannelProvider
-
Whether keepalive will be performed when there are no outstanding RPCs.
- getKeyStore() - Method in class com.google.api.gax.rpc.mtls.MtlsProvider
-
The mutual TLS key store created with the default client certificate on device.
- getLastFlowControlEvent() - Method in class com.google.api.gax.batching.FlowControlEventStats
- getLibraryVersion(Class<?>) - Static method in class com.google.api.gax.core.GaxProperties
-
Returns the version of the library that the
libraryClass
belongs to - getLibraryVersion(Class<?>, String) - Static method in class com.google.api.gax.core.GaxProperties
-
Returns the version of the library that the
libraryClass
belongs to, or a property value in dependencies.properties resource file instead, if the version was not found. - getLimitExceededBehavior() - Method in class com.google.api.gax.batching.DynamicFlowControlSettings
- getLimitExceededBehavior() - Method in class com.google.api.gax.batching.FlowControlSettings
-
The behavior of
FlowController
when the specified limits are exceeded. - getLocalizedMessage() - Method in class com.google.api.gax.rpc.ErrorDetails
-
Provides a localized error message that is safe to return to the user which can be attached to an RPC error
- getManagedChannel() - Method in class com.google.api.gax.httpjson.HttpJsonTransportChannel
-
The channel in use.
- getMaxAttempts() - Method in class com.google.api.gax.retrying.RetrySettings.Builder
-
MaxAttempts defines the maximum number of attempts to perform.
- getMaxAttempts() - Method in class com.google.api.gax.retrying.RetrySettings
-
MaxAttempts defines the maximum number of attempts to perform.
- getMaxChannelCount() - Method in class com.google.api.gax.grpc.ChannelPoolSettings
-
The absolute maximum size of the channel pool.
- getMaxElementCountLimit() - Method in class com.google.api.gax.batching.FlowController
- getMaxInboundMessageSize() - Method in class com.google.api.gax.grpc.InstantiatingGrpcChannelProvider.Builder
-
The maximum message size allowed to be received on the channel.
- getMaxInboundMetadataSize() - Method in class com.google.api.gax.grpc.InstantiatingGrpcChannelProvider.Builder
-
The maximum metadata size allowed to be received on the channel.
- getMaxInboundMetadataSize() - Method in class com.google.api.gax.grpc.InstantiatingGrpcChannelProvider
-
The maximum metadata size allowed to be received on the channel.
- getMaxOutstandingElementCount() - Method in class com.google.api.gax.batching.DynamicFlowControlSettings
-
Maximum number of outstanding elements
FlowController
allows before enforcing flow control. - getMaxOutstandingElementCount() - Method in class com.google.api.gax.batching.FlowControlSettings
-
Maximum number of outstanding elements to keep in memory before enforcing flow control.
- getMaxOutstandingRequestBytes() - Method in class com.google.api.gax.batching.DynamicFlowControlSettings
-
Maximum number of outstanding bytes
FlowController
allows before enforcing flow control. - getMaxOutstandingRequestBytes() - Method in class com.google.api.gax.batching.FlowControlSettings
-
Maximum number of outstanding bytes to keep in memory before enforcing flow control.
- getMaxRequestBytesLimit() - Method in class com.google.api.gax.batching.FlowController
- getMaxRetryDelay() - Method in class com.google.api.gax.retrying.RetrySettings.Builder
-
MaxRetryDelay puts a limit on the value of the retry delay, so that the RetryDelayMultiplier can't increase the retry delay higher than this amount.
- getMaxRetryDelay() - Method in class com.google.api.gax.retrying.RetrySettings
-
MaxRetryDelay puts a limit on the value of the retry delay, so that the RetryDelayMultiplier can't increase the retry delay higher than this amount.
- getMaxRpcsPerChannel() - Method in class com.google.api.gax.grpc.ChannelPoolSettings
-
Threshold to start scaling up the channel pool.
- getMaxRpcTimeout() - Method in class com.google.api.gax.retrying.RetrySettings.Builder
-
MaxRpcTimeout puts a limit on the value of the RPC timeout, so that the RpcTimeoutMultiplier can't increase the RPC timeout higher than this amount.
- getMaxRpcTimeout() - Method in class com.google.api.gax.retrying.RetrySettings
-
MaxRpcTimeout puts a limit on the value of the RPC timeout, so that the RpcTimeoutMultiplier can't increase the RPC timeout higher than this amount.
- getMessageCount() - Method in class com.google.api.gax.rpc.BatchedRequestIssuer
- getMetadata() - Method in class com.google.api.gax.grpc.GrpcResponseMetadata
-
Returns the headers from the gRPC method as Metadata.
- getMetadata() - Method in class com.google.api.gax.httpjson.HttpJsonOperationSnapshot
-
Get metadata for the operation, which can change over the course of the operation.
- getMetadata() - Method in interface com.google.api.gax.longrunning.OperationFuture
-
Gets the metadata of the operation tracked by this
OperationFuture
. - getMetadata() - Method in class com.google.api.gax.longrunning.OperationFutureImpl
- getMetadata() - Method in interface com.google.api.gax.longrunning.OperationSnapshot
-
Get metadata for the operation, which can change over the course of the operation.
- getMetadata() - Method in exception com.google.api.gax.rpc.ApiException
-
Returns additional structured details about this exception.
- getMetadataTransformer() - Method in class com.google.api.gax.rpc.OperationCallSettings.Builder
- getMetadataTransformer() - Method in class com.google.api.gax.rpc.OperationCallSettings
- getMethodDescriptor() - Method in class com.google.api.gax.grpc.GrpcCallSettings
- getMethodDescriptor() - Method in class com.google.api.gax.httpjson.HttpJsonCallSettings
- getMethodDescriptors() - Static method in class com.google.api.gax.httpjson.longrunning.stub.HttpJsonOperationsStub
- getMethodName() - Method in class com.google.api.gax.tracing.SpanName
-
The name of the logical operation being traced.
- getMethodOrFail(Class<?>, String, Class<?>...) - Static method in class com.google.api.gax.nativeimage.NativeImageUtils
-
Returns the method of a class or fails if it is not present.
- getMinChannelCount() - Method in class com.google.api.gax.grpc.ChannelPoolSettings
-
The absolute minimum size of the channel pool.
- getMinElementCountLimit() - Method in class com.google.api.gax.batching.FlowController
- getMinOutstandingElementCount() - Method in class com.google.api.gax.batching.DynamicFlowControlSettings
-
Minimum number of outstanding elements
FlowController
allows before enforcing flow control. - getMinOutstandingRequestBytes() - Method in class com.google.api.gax.batching.DynamicFlowControlSettings
-
Minimum number of outstanding bytes
FlowController
allows before enforcing flow control. - getMinRequestBytesLimit() - Method in class com.google.api.gax.batching.FlowController
- getMinRpcsPerChannel() - Method in class com.google.api.gax.grpc.ChannelPoolSettings
-
Threshold to start scaling down the channel pool.
- getMtlsEndpoint() - Method in class com.google.api.gax.rpc.StubSettings.Builder
- getMtlsEndpoint() - Method in class com.google.api.gax.rpc.StubSettings
- getMtlsEndpointUsagePolicy() - Method in class com.google.api.gax.rpc.mtls.MtlsProvider
-
Returns the current mutual TLS endpoint usage policy.
- getName() - Method in class com.google.api.gax.httpjson.HttpJsonOperationSnapshot
-
The name of the operation.
- getName() - Method in interface com.google.api.gax.longrunning.OperationFuture
-
Returns the value of the name of the operation from the initial operation object returned from the initial call to start the operation.
- getName() - Method in class com.google.api.gax.longrunning.OperationFutureImpl
- getName() - Method in interface com.google.api.gax.longrunning.OperationSnapshot
-
The name of the operation.
- getNextCollection() - Method in class com.google.api.gax.paging.AbstractFixedSizeCollection
- getNextCollection() - Method in interface com.google.api.gax.paging.FixedSizeCollection
-
Retrieves the next FixedSizeCollection using one or more API calls.
- getNextPage() - Method in class com.google.api.gax.paging.AbstractPage
- getNextPage() - Method in interface com.google.api.gax.paging.Page
-
Retrieves the next Page object using the next page token, or
null
if there are no more pages. - getNextPage(int) - Method in class com.google.api.gax.paging.AbstractPage
- getNextPageAsync() - Method in class com.google.api.gax.paging.AbstractPage
- getNextPageAsync() - Method in interface com.google.api.gax.paging.AsyncPage
-
Returns a future for the Page object, retrieved using the next page token.
- getNextPageToken() - Method in class com.google.api.gax.paging.AbstractFixedSizeCollection
- getNextPageToken() - Method in class com.google.api.gax.paging.AbstractPage
- getNextPageToken() - Method in class com.google.api.gax.paging.AbstractPagedListResponse
- getNextPageToken() - Method in interface com.google.api.gax.paging.FixedSizeCollection
-
Returns a page token that can be passed into the API list method to retrieve additional elements.
- getNextPageToken() - Method in interface com.google.api.gax.paging.Page
-
Returns the next page token from the response, or an empty string if there are no more pages.
- getNextPageToken() - Method in interface com.google.api.gax.paging.PagedListResponse
-
Returns the token for the next page or an empty string if no more results.
- getNthPercentile(double) - Method in class com.google.api.gax.core.Distribution
-
Deprecated.
- getOperation(GetOperationRequest) - Method in class com.google.api.gax.httpjson.longrunning.OperationsClient
-
Gets the latest state of a long-running operation.
- getOperation(String) - Method in class com.google.api.gax.httpjson.longrunning.OperationsClient
-
Gets the latest state of a long-running operation.
- getOperation(String) - Method in class com.google.longrunning.OperationsClient
-
Gets the latest state of a long-running operation.
- getOperationCallable() - Method in class com.google.api.gax.httpjson.HttpJsonLongRunningClient
-
Returns a
UnaryCallable
which can issue calls to get the latest state of an operation. - getOperationCallable() - Method in class com.google.api.gax.httpjson.longrunning.OperationsClient
-
Gets the latest state of a long-running operation.
- getOperationCallable() - Method in class com.google.api.gax.httpjson.longrunning.stub.HttpJsonOperationsStub
- getOperationCallable() - Method in class com.google.api.gax.httpjson.longrunning.stub.OperationsStub
- getOperationCallable() - Method in interface com.google.api.gax.rpc.LongRunningClient
-
Returns a
UnaryCallable
which can issue calls to get the latest state of an operation. - getOperationCallable() - Method in class com.google.longrunning.OperationsClient
-
Gets the latest state of a long-running operation.
- getOperationCallable() - Method in class com.google.longrunning.stub.GrpcOperationsStub
- getOperationCallable() - Method in class com.google.longrunning.stub.OperationsStub
- getOperationSettings() - Method in class com.google.api.gax.httpjson.longrunning.OperationsSettings.Builder
-
Returns the builder for the settings used for calls to get.
- getOperationSettings() - Method in class com.google.api.gax.httpjson.longrunning.OperationsSettings
-
Returns the object with the settings used for calls to get.
- getOperationSettings() - Method in class com.google.api.gax.httpjson.longrunning.stub.OperationsStubSettings.Builder
-
Returns the builder for the settings used for calls to get.
- getOperationSettings() - Method in class com.google.api.gax.httpjson.longrunning.stub.OperationsStubSettings
-
Returns the object with the settings used for calls to get.
- getOperationSettings() - Method in class com.google.longrunning.OperationsSettings.Builder
-
Returns the builder for the settings used for calls to getOperation.
- getOperationSettings() - Method in class com.google.longrunning.OperationsSettings
-
Returns the object with the settings used for calls to getOperation.
- getOperationSettings() - Method in class com.google.longrunning.stub.OperationsStubSettings.Builder
-
Returns the builder for the settings used for calls to getOperation.
- getOperationSettings() - Method in class com.google.longrunning.stub.OperationsStubSettings
-
Returns the object with the settings used for calls to getOperation.
- getOperationSnapshotFactory() - Method in class com.google.api.gax.httpjson.ApiMethodDescriptor
- getOption(ApiCallContext.Key<T>) - Method in class com.google.api.gax.grpc.GrpcCallContext
-
Return the api call context option set for this context.
- getOption(ApiCallContext.Key<T>) - Method in class com.google.api.gax.httpjson.HttpJsonCallContext
-
Return the api call context option set for this context.
- getOption(ApiCallContext.Key<T>) - Method in interface com.google.api.gax.rpc.ApiCallContext
-
Return the api call context option set for this context.
- getOption(ApiCallContext.Key<T>) - Method in class com.google.api.gax.rpc.internal.ApiCallContextOptions
-
Get an option.
- getOverallAttemptCount() - Method in class com.google.api.gax.retrying.TimedAttemptSettings
-
The overall attempt count.
- getPage() - Method in class com.google.api.gax.paging.AbstractPagedListResponse
- getPage() - Method in interface com.google.api.gax.paging.PagedListResponse
-
Returns the current page of results.
- getPageDescriptor() - Method in class com.google.api.gax.rpc.PageContext
- getPagedListResponseFactory() - Method in class com.google.api.gax.rpc.PagedCallSettings.Builder
- getPagedListResponseFactory() - Method in class com.google.api.gax.rpc.PagedCallSettings
- getPageElementCount() - Method in class com.google.api.gax.paging.AbstractPage
- getParamsExtractor() - Method in class com.google.api.gax.grpc.GrpcCallSettings
- getPath(MessageFormatT) - Method in interface com.google.api.gax.httpjson.HttpRequestFormatter
- getPath(RequestT) - Method in class com.google.api.gax.httpjson.ProtoMessageRequestFormatter
- getPathTemplate() - Method in interface com.google.api.gax.httpjson.HttpRequestFormatter
-
Path template for endpoint URL path.
- getPathTemplate() - Method in class com.google.api.gax.httpjson.ProtoMessageRequestFormatter
- getPercentile(double) - Method in class com.google.api.gax.core.Distribution
-
Get the percentile of recorded values.
- getPollingAlgorithm() - Method in class com.google.api.gax.rpc.OperationCallSettings.Builder
-
Get the polling algorithm of the operation.
- getPollingAlgorithm() - Method in class com.google.api.gax.rpc.OperationCallSettings
- getPollingFuture() - Method in interface com.google.api.gax.longrunning.OperationFuture
-
Returns the
RetryingFuture
which continues to pollOperationSnapshot
. - getPollingFuture() - Method in class com.google.api.gax.longrunning.OperationFutureImpl
- getPollingRequestFactory() - Method in class com.google.api.gax.httpjson.ApiMethodDescriptor
- getPoolSize() - Method in class com.google.api.gax.grpc.InstantiatingGrpcChannelProvider.Builder
-
Deprecated.
- getPreconditionFailure() - Method in class com.google.api.gax.rpc.ErrorDetails
-
Describes what preconditions have failed.
- getPushingBatcher(PartitionKey) - Method in class com.google.api.gax.rpc.BatcherFactory
-
Provides the ThresholdBatcher corresponding to the given partitionKey, or constructs one if it doesn't exist yet.
- getQueryParamNames(MessageFormatT) - Method in interface com.google.api.gax.httpjson.HttpRequestFormatter
-
Return a map where each entry is the name of a query param mapped to the values of the param.
- getQueryParamNames(RequestT) - Method in class com.google.api.gax.httpjson.ProtoMessageRequestFormatter
- getQuotaFailure() - Method in class com.google.api.gax.rpc.ErrorDetails
-
Describes how a quota check failed.
- getQuotaProjectId() - Method in class com.google.api.gax.rpc.ClientContext
- getQuotaProjectId() - Method in class com.google.api.gax.rpc.ClientSettings.Builder
-
Gets the QuotaProjectId that was previously set on this Builder.
- getQuotaProjectId() - Method in class com.google.api.gax.rpc.ClientSettings
- getQuotaProjectId() - Method in class com.google.api.gax.rpc.StubSettings.Builder
-
Gets the QuotaProjectId that was previously set on this Builder.
- getQuotaProjectId() - Method in class com.google.api.gax.rpc.StubSettings
- getQuotaProjectIdToken() - Method in class com.google.api.gax.rpc.ApiClientHeaderProvider.Builder
- getRandomizedRetryDelay() - Method in class com.google.api.gax.retrying.TimedAttemptSettings
-
Returns randomized attempt delay.
- getReason() - Method in exception com.google.api.gax.rpc.ApiException
-
Returns the reason of the exception.
- getRequest() - Method in class com.google.api.gax.paging.AbstractPage
- getRequest() - Method in class com.google.api.gax.rpc.Batch
- getRequest() - Method in class com.google.api.gax.rpc.PageContext
- getRequestBody(MessageFormatT) - Method in interface com.google.api.gax.httpjson.HttpRequestFormatter
-
Return the serialized inner request body of the given message.
- getRequestBody(RequestT) - Method in class com.google.api.gax.httpjson.ProtoMessageRequestFormatter
- getRequestBuilder() - Method in interface com.google.api.gax.rpc.BatchingDescriptor
-
Get the Builder object for the request type RequestT.
- getRequestByteThreshold() - Method in class com.google.api.gax.batching.BatchingSettings
-
Get the request byte threshold to use for batching.
- getRequestFormatter() - Method in class com.google.api.gax.httpjson.ApiMethodDescriptor.Builder
- getRequestFormatter() - Method in class com.google.api.gax.httpjson.ApiMethodDescriptor
- getRequestInfo() - Method in class com.google.api.gax.rpc.ErrorDetails
-
Contains metadata about the request that clients can attach when filing a bug or providing other forms of feedback.
- getRequestIssuerList() - Method in class com.google.api.gax.rpc.Batch
- getRequestMetadata() - Method in class com.google.api.gax.rpc.internal.QuotaProjectIdHidingCredentials
- getRequestMetadata(URI) - Method in class com.google.api.gax.rpc.internal.QuotaProjectIdHidingCredentials
- getResourceHeaderKey() - Method in class com.google.api.gax.rpc.ApiClientHeaderProvider.Builder
- getResourceInfo() - Method in class com.google.api.gax.rpc.ErrorDetails
-
Describes the resource that is being accessed.
- getResourceToken() - Method in class com.google.api.gax.rpc.ApiClientHeaderProvider.Builder
- getResponse() - Method in class com.google.api.gax.httpjson.HttpJsonOperationSnapshot
-
If the operation is done and successful, returns the response; if the operation is not done or if it is failed, returns null.
- getResponse() - Method in interface com.google.api.gax.longrunning.OperationSnapshot
-
If the operation is done and successful, returns the response; if the operation is not done or if it is failed, returns null.
- getResponse() - Method in class com.google.api.gax.paging.AbstractPage
- getResponseParser() - Method in class com.google.api.gax.httpjson.ApiMethodDescriptor
- getResponseTransformer() - Method in class com.google.api.gax.rpc.OperationCallSettings.Builder
- getResponseTransformer() - Method in class com.google.api.gax.rpc.OperationCallSettings
- getResultAlgorithm() - Method in class com.google.api.gax.retrying.RetryAlgorithm
- getResultFuture() - Method in class com.google.api.gax.batching.BatchEntry
- getResumeRequest(RequestT) - Method in class com.google.api.gax.retrying.SimpleStreamResumptionStrategy
- getResumeRequest(RequestT) - Method in interface com.google.api.gax.retrying.StreamResumptionStrategy
-
Called when a stream needs to be restarted, the implementation should generate a request that will yield a new stream whose first response would come right after the last response received by processResponse.
- getResumptionStrategy() - Method in class com.google.api.gax.rpc.ServerStreamingCallSettings.Builder
- getResumptionStrategy() - Method in class com.google.api.gax.rpc.ServerStreamingCallSettings
-
See the class documentation of
ServerStreamingCallSettings
andStreamResumptionStrategy
for a description of what the StreamResumptionStrategy does. - getRetryableCodes() - Method in class com.google.api.gax.grpc.GrpcCallContext
- getRetryableCodes() - Method in class com.google.api.gax.httpjson.HttpJsonCallContext
- getRetryableCodes() - Method in interface com.google.api.gax.retrying.RetryingContext
-
Returns the retryable codes to use with this context, or
null
if the default retryable codes should be used. - getRetryableCodes() - Method in class com.google.api.gax.rpc.ServerStreamingCallSettings.Builder
- getRetryableCodes() - Method in class com.google.api.gax.rpc.ServerStreamingCallSettings
-
See the class documentation of
ServerStreamingCallSettings
for a description of what retryableCodes do. - getRetryableCodes() - Method in class com.google.api.gax.rpc.UnaryCallSettings.Builder
-
See the class documentation of
UnaryCallSettings
for a description of what retryable codes do. - getRetryableCodes() - Method in class com.google.api.gax.rpc.UnaryCallSettings
-
See the class documentation of
UnaryCallSettings
for a description of what retryable codes do. - getRetryDelay() - Method in class com.google.api.gax.retrying.TimedAttemptSettings
-
Returns the calculated retry delay.
- getRetryDelayMultiplier() - Method in class com.google.api.gax.retrying.RetrySettings.Builder
-
RetryDelayMultiplier controls the change in retry delay.
- getRetryDelayMultiplier() - Method in class com.google.api.gax.retrying.RetrySettings
-
RetryDelayMultiplier controls the change in retry delay.
- getRetryInfo() - Method in class com.google.api.gax.rpc.ErrorDetails
-
Describes when the clients can retry a failed request.
- getRetrySettings() - Method in class com.google.api.gax.grpc.GrpcCallContext
- getRetrySettings() - Method in class com.google.api.gax.httpjson.HttpJsonCallContext
- getRetrySettings() - Method in interface com.google.api.gax.retrying.RetryingContext
-
Returns the
RetrySettings
to use with this context, ornull
if the defaultRetrySettings
should be used. - getRetrySettings() - Method in class com.google.api.gax.rpc.ServerStreamingCallSettings.Builder
- getRetrySettings() - Method in class com.google.api.gax.rpc.ServerStreamingCallSettings
-
See the class documentation of
ServerStreamingCallSettings
for a description of what retrySettings do. - getRetrySettings() - Method in class com.google.api.gax.rpc.UnaryCallSettings.Builder
-
Returns an immutable
RetrySettings
currently set in this Builder. - getRetrySettings() - Method in class com.google.api.gax.rpc.UnaryCallSettings
-
See the class documentation of
UnaryCallSettings
for a description of what retry settings do. - getRpcTimeout() - Method in class com.google.api.gax.retrying.TimedAttemptSettings
-
Returns rpc timeout used for this attempt.
- getRpcTimeoutMultiplier() - Method in class com.google.api.gax.retrying.RetrySettings.Builder
-
See the class documentation of
RetrySettings
for a description of what this value does. - getRpcTimeoutMultiplier() - Method in class com.google.api.gax.retrying.RetrySettings
-
RpcTimeoutMultiplier controls the change in RPC timeout.
- getScopesToApply() - Method in class com.google.api.gax.core.GoogleCredentialsProvider.Builder
-
The scopes previously provided.
- getScopesToApply() - Method in class com.google.api.gax.core.GoogleCredentialsProvider
- getSettings() - Method in class com.google.api.gax.httpjson.longrunning.OperationsClient
- getSettings() - Method in class com.google.longrunning.OperationsClient
- getStatusCode() - Method in exception com.google.api.gax.httpjson.HttpJsonStatusRuntimeException
- getStatusCode() - Method in exception com.google.api.gax.rpc.ApiException
-
Returns the status code of the underlying exception.
- getStatusMessage() - Method in class com.google.api.gax.httpjson.HttpJsonMetadata
- getStreamIdleTimeout() - Method in class com.google.api.gax.grpc.GrpcCallContext
-
The stream idle timeout set for this context.
- getStreamIdleTimeout() - Method in class com.google.api.gax.httpjson.HttpJsonCallContext
-
The stream idle timeout set for this context.
- getStreamIdleTimeout() - Method in interface com.google.api.gax.rpc.ApiCallContext
-
The stream idle timeout set for this context.
- getStreamWaitTimeout() - Method in class com.google.api.gax.grpc.GrpcCallContext
-
The stream wait timeout set for this context.
- getStreamWaitTimeout() - Method in class com.google.api.gax.httpjson.HttpJsonCallContext
-
The stream wait timeout set for this context.
- getStreamWaitTimeout() - Method in interface com.google.api.gax.rpc.ApiCallContext
-
Return the stream wait timeout set for this context.
- getStreamWatchdog() - Method in class com.google.api.gax.rpc.ClientContext
- getStreamWatchdogCheckInterval() - Method in class com.google.api.gax.rpc.ClientContext
- getStreamWatchdogCheckInterval() - Method in class com.google.api.gax.rpc.StubSettings.Builder
- getStreamWatchdogCheckInterval() - Method in class com.google.api.gax.rpc.StubSettings
- getStreamWatchdogProvider() - Method in class com.google.api.gax.rpc.StubSettings.Builder
-
Gets the
WatchdogProvider
that was previously set on this Builder. - getStreamWatchdogProvider() - Method in class com.google.api.gax.rpc.StubSettings
- getStub() - Method in class com.google.api.gax.httpjson.longrunning.OperationsClient
- getStub() - Method in class com.google.longrunning.OperationsClient
- getStubSettings() - Method in class com.google.api.gax.rpc.ClientSettings.Builder
- getStubSettings() - Method in class com.google.api.gax.rpc.ClientSettings
- getStubSettingsBuilder() - Method in class com.google.api.gax.httpjson.longrunning.OperationsSettings.Builder
- getStubSettingsBuilder() - Method in class com.google.longrunning.OperationsSettings.Builder
- getThreadFactory() - Method in class com.google.api.gax.core.InstantiatingExecutorProvider.Builder
- getThreadFactory() - Method in class com.google.api.gax.core.InstantiatingExecutorProvider
-
Return a thread-factory to create gax processing threads so we can name them appropriately
- getThrottledTime(TimeUnit) - Method in class com.google.api.gax.batching.FlowControlEventStats.FlowControlEvent
- getTimedAlgorithm() - Method in class com.google.api.gax.retrying.RetryAlgorithm
- getTimeout() - Method in class com.google.api.gax.grpc.GrpcCallContext
- getTimeout() - Method in class com.google.api.gax.httpjson.HttpJsonCallContext
- getTimeout() - Method in interface com.google.api.gax.rpc.ApiCallContext
-
Returns the configured per-RPC timeout.
- getTimestampMs() - Method in class com.google.api.gax.batching.FlowControlEventStats.FlowControlEvent
- getTotalTimeout() - Method in class com.google.api.gax.retrying.RetrySettings.Builder
-
TotalTimeout has ultimate control over how long the logic should keep trying the remote call until it gives up completely.
- getTotalTimeout() - Method in class com.google.api.gax.retrying.RetrySettings
-
TotalTimeout has ultimate control over how long the logic should keep trying the remote call until it gives up completely.
- getTracer() - Method in class com.google.api.gax.grpc.GrpcCallContext
-
The
ApiTracer
that was previously set for this context. - getTracer() - Method in class com.google.api.gax.httpjson.HttpJsonCallContext
- getTracer() - Method in interface com.google.api.gax.retrying.RetryingContext
-
Returns the
ApiTracer
associated with the current operation. - getTracer() - Method in interface com.google.api.gax.rpc.ApiCallContext
-
The
ApiTracer
that was previously set for this context. - getTracerFactory() - Method in class com.google.api.gax.rpc.ClientContext
-
Gets the
ApiTracerFactory
that will be used to generate traces for operations. - getTracerFactory() - Method in class com.google.api.gax.rpc.StubSettings.Builder
- getTracerFactory() - Method in class com.google.api.gax.rpc.StubSettings
-
Gets the configured
ApiTracerFactory
that will be used to generate traces for operations. - getTrailingMetadata() - Method in class com.google.api.gax.grpc.GrpcResponseMetadata
-
Returns the trailers from the gRPC method as Metadata.
- getTransportChannel() - Method in class com.google.api.gax.grpc.InstantiatingGrpcChannelProvider
- getTransportChannel() - Method in class com.google.api.gax.httpjson.InstantiatingHttpJsonChannelProvider
- getTransportChannel() - Method in class com.google.api.gax.rpc.ClientContext
- getTransportChannel() - Method in class com.google.api.gax.rpc.FixedTransportChannelProvider
- getTransportChannel() - Method in interface com.google.api.gax.rpc.TransportChannelProvider
-
Provides a Transport, which could either be a new instance for every call, or the same instance, depending on the implementation.
- getTransportChannelProvider() - Method in class com.google.api.gax.rpc.ClientSettings.Builder
-
Gets the TransportProvider that was previously set on this Builder.
- getTransportChannelProvider() - Method in class com.google.api.gax.rpc.ClientSettings
- getTransportChannelProvider() - Method in class com.google.api.gax.rpc.StubSettings.Builder
-
Gets the TransportProvider that was previously set on this Builder.
- getTransportChannelProvider() - Method in class com.google.api.gax.rpc.StubSettings
- getTransportCode() - Method in class com.google.api.gax.grpc.GrpcStatusCode
- getTransportCode() - Method in class com.google.api.gax.httpjson.HttpJsonStatusCode
-
Returns the status code from the http call.
- getTransportCode() - Method in interface com.google.api.gax.rpc.StatusCode
-
Return the transport-specific status code value.
- getTransportName() - Method in class com.google.api.gax.grpc.GrpcTransportChannel
- getTransportName() - Method in class com.google.api.gax.grpc.InstantiatingGrpcChannelProvider
- getTransportName() - Method in class com.google.api.gax.httpjson.HttpJsonTransportChannel
- getTransportName() - Method in class com.google.api.gax.httpjson.InstantiatingHttpJsonChannelProvider
- getTransportName() - Method in class com.google.api.gax.rpc.FixedTransportChannelProvider
- getTransportName() - Method in interface com.google.api.gax.rpc.TransportChannel
-
The name of the transport.
- getTransportName() - Method in interface com.google.api.gax.rpc.TransportChannelProvider
-
The name of the transport.
- getTransportToken() - Method in class com.google.api.gax.rpc.ApiClientHeaderProvider.Builder
- getType() - Method in class com.google.api.gax.httpjson.ApiMethodDescriptor
- getTypeRegistry() - Method in class com.google.api.gax.httpjson.HttpJsonCallOptions
- getTypeRegistry() - Method in class com.google.api.gax.httpjson.HttpJsonCallSettings
- getUseJwtAccessWithScope() - Method in class com.google.api.gax.core.GoogleCredentialsProvider.Builder
-
The UseJwtAccessWithScope value previously provided.
- getUseJwtAccessWithScope() - Method in class com.google.api.gax.core.GoogleCredentialsProvider
- getUserAgentHeader() - Method in class com.google.api.gax.grpc.GrpcHeaderInterceptor
- getUserAgentValue(Map<String, String>) - Static method in class com.google.api.gax.httpjson.HttpHeadersUtils
- getValues() - Method in class com.google.api.gax.paging.AbstractFixedSizeCollection
- getValues() - Method in class com.google.api.gax.paging.AbstractPage
- getValues() - Method in interface com.google.api.gax.paging.FixedSizeCollection
-
Returns an iterable over the elements in this FixedSizeCollection.
- getValues() - Method in interface com.google.api.gax.paging.Page
-
Returns an iterable over the elements in this page.
- getWatchdog() - Method in class com.google.api.gax.rpc.FixedWatchdogProvider
- getWatchdog() - Method in class com.google.api.gax.rpc.InstantiatingWatchdogProvider
- getWatchdog() - Method in interface com.google.api.gax.rpc.WatchdogProvider
- getWatchdogCheckInterval() - Method in class com.google.api.gax.rpc.ClientSettings.Builder
- getWatchdogCheckInterval() - Method in class com.google.api.gax.rpc.ClientSettings
- getWatchdogProvider() - Method in class com.google.api.gax.rpc.ClientSettings.Builder
- getWatchdogProvider() - Method in class com.google.api.gax.rpc.ClientSettings
- GoogleCredentialsProvider - Class in com.google.api.gax.core
-
GoogleCredentialsProvider acquires credentials using Application Default Credentials.
- GoogleCredentialsProvider() - Constructor for class com.google.api.gax.core.GoogleCredentialsProvider
- GoogleCredentialsProvider.Builder - Class in com.google.api.gax.core
- GrpcCallableFactory - Class in com.google.api.gax.grpc
-
Class with utility methods to create grpc-based direct callables.
- GrpcCallContext - Class in com.google.api.gax.grpc
-
GrpcCallContext encapsulates context data used to make a grpc call.
- GrpcCallSettings<RequestT,ResponseT> - Class in com.google.api.gax.grpc
-
Grpc-specific settings for creating callables.
- GrpcCallSettings.Builder<RequestT,ResponseT> - Class in com.google.api.gax.grpc
- GrpcHeaderInterceptor - Class in com.google.api.gax.grpc
-
An interceptor to handle custom headers.
- GrpcHeaderInterceptor(Map<String, String>) - Constructor for class com.google.api.gax.grpc.GrpcHeaderInterceptor
- GrpcInterceptorProvider - Interface in com.google.api.gax.grpc
-
Provider of custom gRPC ClientInterceptors.
- GrpcOperationsCallableFactory - Class in com.google.longrunning.stub
-
gRPC callable factory implementation for Google Long Running Operations API.
- GrpcOperationsCallableFactory() - Constructor for class com.google.longrunning.stub.GrpcOperationsCallableFactory
- GrpcOperationsStub - Class in com.google.longrunning.stub
-
gRPC stub implementation for Google Long Running Operations API.
- GrpcOperationsStub(OperationsStubSettings, ClientContext) - Constructor for class com.google.longrunning.stub.GrpcOperationsStub
-
Constructs an instance of GrpcOperationsStub, using the given settings.
- GrpcOperationsStub(OperationsStubSettings, ClientContext, GrpcStubCallableFactory) - Constructor for class com.google.longrunning.stub.GrpcOperationsStub
-
Constructs an instance of GrpcOperationsStub, using the given settings.
- GrpcRawCallableFactory - Class in com.google.api.gax.grpc
-
Class with utility methods to create low level grpc-based direct callables.
- GrpcResponseMetadata - Class in com.google.api.gax.grpc
-
GrpcResponseMetadata provides a mechanism to access the headers and trailers returned by a gRPC client method.
- GrpcResponseMetadata() - Constructor for class com.google.api.gax.grpc.GrpcResponseMetadata
- GrpcStatusCode - Class in com.google.api.gax.grpc
-
A failure code specific to a gRPC call.
- GrpcStatusCode() - Constructor for class com.google.api.gax.grpc.GrpcStatusCode
- GrpcStubCallableFactory - Interface in com.google.api.gax.grpc
- GrpcTransportChannel - Class in com.google.api.gax.grpc
-
Implementation of TransportChannel based on gRPC.
- GrpcTransportChannel() - Constructor for class com.google.api.gax.grpc.GrpcTransportChannel
- GrpcTransportChannel.Builder - Class in com.google.api.gax.grpc
H
- halfClose() - Method in class com.google.api.gax.httpjson.ForwardingHttpJsonClientCall
- halfClose() - Method in class com.google.api.gax.httpjson.HttpJsonClientCall
-
Close the call for request message sending.
- hashCode() - Method in class com.google.api.gax.batching.PartitionKey
- hashCode() - Method in class com.google.api.gax.grpc.GrpcCallContext
- hashCode() - Method in class com.google.api.gax.httpjson.HttpJsonCallContext
- hashCode() - Method in class com.google.api.gax.httpjson.HttpJsonStatusCode
- hashCode() - Method in class com.google.api.gax.rpc.UnaryCallSettings
- hashCode() - Method in class com.google.api.gax.tracing.OpencensusTracerFactory
- hasNextCollection() - Method in class com.google.api.gax.paging.AbstractFixedSizeCollection
- hasNextCollection() - Method in interface com.google.api.gax.paging.FixedSizeCollection
-
Returns true if there are more elements that can be retrieved from the API.
- hasNextPage() - Method in class com.google.api.gax.paging.AbstractPage
- hasNextPage() - Method in interface com.google.api.gax.paging.Page
-
Returns true if there are more pages that can be retrieved from the API.
- hasRequestMetadata() - Method in class com.google.api.gax.rpc.internal.QuotaProjectIdHidingCredentials
- hasRequestMetadataOnly() - Method in class com.google.api.gax.rpc.internal.QuotaProjectIdHidingCredentials
- hasSeenResponses() - Method in exception com.google.api.gax.retrying.ServerStreamingAttemptException
-
If the current RPC attempt has seen any streamed messages.
- HeaderProvider - Interface in com.google.api.gax.rpc
-
Provider of headers to put on http requests.
- Headers - Class in com.google.api.gax.rpc.internal
- Headers() - Constructor for class com.google.api.gax.rpc.internal.Headers
- HttpHeadersUtils - Class in com.google.api.gax.httpjson
-
This class is for internal use only and is public for technical reasons.
- HttpHeadersUtils() - Constructor for class com.google.api.gax.httpjson.HttpHeadersUtils
- HttpJsonCallableFactory - Class in com.google.api.gax.httpjson
-
Class with utility methods to create http/json-based direct callables.
- HttpJsonCallContext - Class in com.google.api.gax.httpjson
-
HttpJsonCallContext encapsulates context data used to make an http-json call.
- HttpJsonCallOptions - Class in com.google.api.gax.httpjson
-
Options for an http-json call, including deadline and credentials.
- HttpJsonCallOptions() - Constructor for class com.google.api.gax.httpjson.HttpJsonCallOptions
- HttpJsonCallOptions.Builder - Class in com.google.api.gax.httpjson
- HttpJsonCallSettings<RequestT,ResponseT> - Class in com.google.api.gax.httpjson
-
HTTP-specific settings for creating callables.
- HttpJsonCallSettings.Builder<RequestT,ResponseT> - Class in com.google.api.gax.httpjson
- HttpJsonChannel - Interface in com.google.api.gax.httpjson
-
HttpJsonChannel contains the functionality to issue http-json calls.
- HttpJsonClientCall<RequestT,ResponseT> - Class in com.google.api.gax.httpjson
-
An instance of a call to a remote method.
- HttpJsonClientCall() - Constructor for class com.google.api.gax.httpjson.HttpJsonClientCall
- HttpJsonClientCall.Listener<T> - Class in com.google.api.gax.httpjson
-
Callbacks for receiving metadata, response messages and completion status from the server.
- HttpJsonClientInterceptor - Interface in com.google.api.gax.httpjson
-
Interface for intercepting outgoing calls before they are dispatched by a
HttpJsonChannel
. - HttpJsonHeaderEnhancer - Interface in com.google.api.gax.httpjson
-
Interface for functionality to enhance headers for an http-json call.
- HttpJsonHeaderEnhancers - Class in com.google.api.gax.httpjson
-
Utility class that creates instances of
HttpJsonHeaderEnhancer
. - HttpJsonInterceptorProvider - Interface in com.google.api.gax.httpjson
-
Provider of custom REST ClientInterceptors.
- HttpJsonLongRunningClient<RequestT,OperationT> - Class in com.google.api.gax.httpjson
-
Implementation of LongRunningClient based on REST transport.
- HttpJsonLongRunningClient(UnaryCallable<RequestT, OperationT>, OperationSnapshotFactory<RequestT, OperationT>, PollingRequestFactory<RequestT>) - Constructor for class com.google.api.gax.httpjson.HttpJsonLongRunningClient
- HttpJsonMetadata - Class in com.google.api.gax.httpjson
- HttpJsonMetadata() - Constructor for class com.google.api.gax.httpjson.HttpJsonMetadata
- HttpJsonOperationsCallableFactory - Class in com.google.api.gax.httpjson.longrunning.stub
-
REST callable factory implementation for the Operations service API.
- HttpJsonOperationsCallableFactory() - Constructor for class com.google.api.gax.httpjson.longrunning.stub.HttpJsonOperationsCallableFactory
- HttpJsonOperationSnapshot - Class in com.google.api.gax.httpjson
-
Implementation of OperationSnapshot based on REST transport.
- HttpJsonOperationSnapshot.Builder - Class in com.google.api.gax.httpjson
- HttpJsonOperationSnapshotCallable<RequestT,OperationT> - Class in com.google.api.gax.httpjson
-
A
UnaryCallable
that wraps a UnaryCallable returning an Operation and returns an OperationSnapshot instead. - HttpJsonOperationSnapshotCallable(UnaryCallable<RequestT, OperationT>, OperationSnapshotFactory<RequestT, OperationT>) - Constructor for class com.google.api.gax.httpjson.HttpJsonOperationSnapshotCallable
- HttpJsonOperationsStub - Class in com.google.api.gax.httpjson.longrunning.stub
-
REST stub implementation for the Operations service API.
- HttpJsonOperationsStub(OperationsStubSettings, ClientContext) - Constructor for class com.google.api.gax.httpjson.longrunning.stub.HttpJsonOperationsStub
-
Constructs an instance of HttpJsonOperationsStub, using the given settings.
- HttpJsonOperationsStub(OperationsStubSettings, ClientContext, HttpJsonStubCallableFactory, TypeRegistry) - Constructor for class com.google.api.gax.httpjson.longrunning.stub.HttpJsonOperationsStub
-
Constructs an instance of HttpJsonOperationsStub, using the given settings.
- HttpJsonStatusCode - Class in com.google.api.gax.httpjson
-
A failure code specific to an HTTP call.
- HttpJsonStatusRuntimeException - Exception in com.google.api.gax.httpjson
-
HTTP status code in RuntimeException form, for propagating status code information via exceptions.
- HttpJsonStatusRuntimeException(int, String, Throwable) - Constructor for exception com.google.api.gax.httpjson.HttpJsonStatusRuntimeException
- HttpJsonStubCallableFactory<OperationT,OperationsStub extends BackgroundResource> - Interface in com.google.api.gax.httpjson
- HttpJsonTransportChannel - Class in com.google.api.gax.httpjson
-
Implementation of TransportChannel based on http/json.
- HttpJsonTransportChannel() - Constructor for class com.google.api.gax.httpjson.HttpJsonTransportChannel
- HttpJsonTransportChannel.Builder - Class in com.google.api.gax.httpjson
- HttpRequestFormatter<MessageFormatT> - Interface in com.google.api.gax.httpjson
-
Interface for classes that create parts of HTTP requests from a parameterized message.
- HttpResponseParser<MessageFormatT> - Interface in com.google.api.gax.httpjson
-
Interface for classes that parse parts of HTTP responses into the parameterized message type.
I
- Ignore - com.google.api.gax.batching.FlowController.LimitExceededBehavior
-
Disables flow-control.
- immediateOperationFuture(OperationSnapshot) - Static method in class com.google.api.gax.longrunning.OperationFutures
-
Creates an already-completed
OperationFuture
, useful for testing. - increaseThresholds(long, long) - Method in class com.google.api.gax.batching.FlowController
-
Increase flow control limits to allow extra elementSteps elements and byteSteps request bytes before enforcing flow control.
- injectPageSize(RequestT, int) - Method in interface com.google.api.gax.rpc.PagedListDescriptor
-
Injects page size setting into the request.
- injectToken(RequestT, String) - Method in interface com.google.api.gax.rpc.PagedListDescriptor
-
Injects a page token into the request.
- inScope() - Method in interface com.google.api.gax.tracing.ApiTracer
-
Asks the underlying implementation to install itself as a thread local.
- inScope() - Method in class com.google.api.gax.tracing.BaseApiTracer
- inScope() - Method in class com.google.api.gax.tracing.OpencensusTracer
-
Asks the underlying implementation to install itself as a thread local.
- InstantiatingExecutorProvider - Class in com.google.api.gax.core
-
InstantiatingChannelProvider is an ExecutorProvider which constructs a new ScheduledExecutorService every time getExecutor() is called.
- InstantiatingExecutorProvider.Builder - Class in com.google.api.gax.core
- InstantiatingGrpcChannelProvider - Class in com.google.api.gax.grpc
-
InstantiatingGrpcChannelProvider is a TransportChannelProvider which constructs a gRPC ManagedChannel with a number of configured inputs every time getChannel(...) is called.
- InstantiatingGrpcChannelProvider.Builder - Class in com.google.api.gax.grpc
- InstantiatingHttpJsonChannelProvider - Class in com.google.api.gax.httpjson
-
InstantiatingHttpJsonChannelProvider is a TransportChannelProvider which constructs a
ManagedHttpJsonChannel
with a number of configured inputs every time getChannel(...) is called. - InstantiatingHttpJsonChannelProvider.Builder - Class in com.google.api.gax.httpjson
- InstantiatingWatchdogProvider - Class in com.google.api.gax.rpc
-
A watchdog provider which instantiates a new provider on every request.
- interceptCall(ApiMethodDescriptor<ReqT, RespT>, HttpJsonCallOptions, HttpJsonChannel) - Method in interface com.google.api.gax.httpjson.HttpJsonClientInterceptor
- interceptCall(MethodDescriptor<ReqT, RespT>, CallOptions, Channel) - Method in class com.google.api.gax.grpc.GrpcHeaderInterceptor
- INTERNAL - com.google.api.gax.rpc.StatusCode.Code
- internalCall(ResponseObserver<ResponseT>, ClientStreamReadyObserver<RequestT>, ApiCallContext) - Method in class com.google.api.gax.rpc.BidiStreamingCallable
-
The "base" method from which other forms of
call
s are derived. - internalCall(ResponseObserver<ResponseT>, ClientStreamReadyObserver<RequestT>, ApiCallContext) - Method in class com.google.api.gax.tracing.TracedBidiCallable
- InternalException - Exception in com.google.api.gax.rpc
-
Exception thrown due to internal errors.
- InternalException(String, Throwable, StatusCode, boolean) - Constructor for exception com.google.api.gax.rpc.InternalException
- InternalException(Throwable, StatusCode, boolean) - Constructor for exception com.google.api.gax.rpc.InternalException
- InternalException(Throwable, StatusCode, boolean, ErrorDetails) - Constructor for exception com.google.api.gax.rpc.InternalException
- INVALID_ARGUMENT - com.google.api.gax.rpc.StatusCode.Code
- InvalidArgumentException - Exception in com.google.api.gax.rpc
-
Exception thrown when client specified an invalid argument.
- InvalidArgumentException(String, Throwable, StatusCode, boolean) - Constructor for exception com.google.api.gax.rpc.InvalidArgumentException
- InvalidArgumentException(Throwable, StatusCode, boolean) - Constructor for exception com.google.api.gax.rpc.InvalidArgumentException
- InvalidArgumentException(Throwable, StatusCode, boolean, ErrorDetails) - Constructor for exception com.google.api.gax.rpc.InvalidArgumentException
- isCancelled() - Method in class com.google.api.gax.longrunning.OperationFutureImpl
- isDone() - Method in class com.google.api.gax.httpjson.HttpJsonOperationSnapshot
-
Returns true if the operation is complete or failed, false otherwise.
- isDone() - Method in class com.google.api.gax.longrunning.OperationFutureImpl
- isDone() - Method in interface com.google.api.gax.longrunning.OperationSnapshot
-
Returns true if the operation is complete or failed, false otherwise.
- isJittered() - Method in class com.google.api.gax.retrying.RetrySettings.Builder
-
Jitter determines if the delay time should be randomized.
- isJittered() - Method in class com.google.api.gax.retrying.RetrySettings
-
Deprecated.Retries always jitter.
- isPreemptiveRefreshEnabled() - Method in class com.google.api.gax.grpc.ChannelPoolSettings
-
If all of the channels should be replaced on an hourly basis.
- isReceiveReady() - Method in class com.google.api.gax.rpc.ServerStream
-
Returns true if the next call to the iterator's hasNext() or next() is guaranteed to be nonblocking.
- isRetryable() - Method in exception com.google.api.gax.rpc.ApiException
-
Returns whether the failed request can be retried.
- isSendReady() - Method in class com.google.api.gax.rpc.BidiStream
-
Reports whether a message can be sent without requiring excessive buffering internally.
- isSendReady() - Method in interface com.google.api.gax.rpc.ClientStream
-
Reports whether a new request can be sent without excessive buffering.
- isShutdown() - Method in interface com.google.api.gax.core.BackgroundResource
-
Returns true if this background resource has been shut down.
- isShutdown() - Method in class com.google.api.gax.core.BackgroundResourceAggregation
- isShutdown() - Method in class com.google.api.gax.core.BaseBackgroundResource
- isShutdown() - Method in class com.google.api.gax.core.ExecutorAsBackgroundResource
- isShutdown() - Method in class com.google.api.gax.grpc.GrpcTransportChannel
- isShutdown() - Method in class com.google.api.gax.httpjson.HttpJsonTransportChannel
- isShutdown() - Method in class com.google.api.gax.httpjson.longrunning.OperationsClient
- isShutdown() - Method in class com.google.api.gax.httpjson.longrunning.stub.HttpJsonOperationsStub
- isShutdown() - Method in class com.google.api.gax.httpjson.ManagedHttpJsonChannel
- isShutdown() - Method in class com.google.api.gax.rpc.Watchdog
- isShutdown() - Method in class com.google.longrunning.OperationsClient
- isShutdown() - Method in class com.google.longrunning.stub.GrpcOperationsStub
- isTerminated() - Method in interface com.google.api.gax.core.BackgroundResource
-
Returns true if all work has completed following shut down.
- isTerminated() - Method in class com.google.api.gax.core.BackgroundResourceAggregation
- isTerminated() - Method in class com.google.api.gax.core.BaseBackgroundResource
- isTerminated() - Method in class com.google.api.gax.core.ExecutorAsBackgroundResource
- isTerminated() - Method in class com.google.api.gax.grpc.GrpcTransportChannel
- isTerminated() - Method in class com.google.api.gax.httpjson.HttpJsonTransportChannel
- isTerminated() - Method in class com.google.api.gax.httpjson.longrunning.OperationsClient
- isTerminated() - Method in class com.google.api.gax.httpjson.longrunning.stub.HttpJsonOperationsStub
- isTerminated() - Method in class com.google.api.gax.httpjson.ManagedHttpJsonChannel
- isTerminated() - Method in class com.google.api.gax.rpc.Watchdog
- isTerminated() - Method in class com.google.longrunning.OperationsClient
- isTerminated() - Method in class com.google.longrunning.stub.GrpcOperationsStub
- isThresholdReached() - Method in interface com.google.api.gax.batching.BatchingThreshold
-
Any calls into this function from ThresholdBatcher will be under a lock.
- isThresholdReached() - Method in class com.google.api.gax.batching.NumericThreshold
- iterateAll() - Method in class com.google.api.gax.paging.AbstractPage
- iterateAll() - Method in class com.google.api.gax.paging.AbstractPagedListResponse
- iterateAll() - Method in interface com.google.api.gax.paging.Page
-
Returns an iterable that traverses all of the elements of the underlying data source.
- iterateAll() - Method in interface com.google.api.gax.paging.PagedListResponse
-
Returns an iterable that traverses all of the elements of the underlying data source.
- iterateFixedSizeCollections(int) - Method in class com.google.api.gax.paging.AbstractPagedListResponse
- iterateFixedSizeCollections(int) - Method in interface com.google.api.gax.paging.PagedListResponse
-
Returns an iterable over fixed size collections of results.
- iteratePages() - Method in class com.google.api.gax.paging.AbstractPagedListResponse
- iteratePages() - Method in interface com.google.api.gax.paging.PagedListResponse
-
Return an iterable over all Page objects.
- iterator() - Method in class com.google.api.gax.rpc.ServerStream
L
- Listener() - Constructor for class com.google.api.gax.httpjson.HttpJsonClientCall.Listener
- listOperations(ListOperationsRequest) - Method in class com.google.api.gax.httpjson.longrunning.OperationsClient
-
Lists operations that match the specified filter in the request.
- listOperations(ListOperationsRequest) - Method in class com.google.longrunning.OperationsClient
-
Lists operations that match the specified filter in the request.
- listOperations(String, String) - Method in class com.google.api.gax.httpjson.longrunning.OperationsClient
-
Lists operations that match the specified filter in the request.
- listOperations(String, String) - Method in class com.google.longrunning.OperationsClient
-
Lists operations that match the specified filter in the request.
- listOperationsCallable() - Method in class com.google.api.gax.httpjson.longrunning.OperationsClient
-
Lists operations that match the specified filter in the request.
- listOperationsCallable() - Method in class com.google.api.gax.httpjson.longrunning.stub.HttpJsonOperationsStub
- listOperationsCallable() - Method in class com.google.api.gax.httpjson.longrunning.stub.OperationsStub
- listOperationsCallable() - Method in class com.google.longrunning.OperationsClient
-
Lists operations that match the specified filter in the request.
- listOperationsCallable() - Method in class com.google.longrunning.stub.GrpcOperationsStub
- listOperationsCallable() - Method in class com.google.longrunning.stub.OperationsStub
- listOperationsPagedCallable() - Method in class com.google.api.gax.httpjson.longrunning.OperationsClient
-
Lists operations that match the specified filter in the request.
- listOperationsPagedCallable() - Method in class com.google.api.gax.httpjson.longrunning.stub.HttpJsonOperationsStub
- listOperationsPagedCallable() - Method in class com.google.api.gax.httpjson.longrunning.stub.OperationsStub
- listOperationsPagedCallable() - Method in class com.google.longrunning.OperationsClient
-
Lists operations that match the specified filter in the request.
- listOperationsPagedCallable() - Method in class com.google.longrunning.stub.GrpcOperationsStub
- listOperationsPagedCallable() - Method in class com.google.longrunning.stub.OperationsStub
- listOperationsSettings() - Method in class com.google.api.gax.httpjson.longrunning.OperationsSettings.Builder
-
Returns the builder for the settings used for calls to listOperations.
- listOperationsSettings() - Method in class com.google.api.gax.httpjson.longrunning.OperationsSettings
-
Returns the object with the settings used for calls to listOperations.
- listOperationsSettings() - Method in class com.google.api.gax.httpjson.longrunning.stub.OperationsStubSettings.Builder
-
Returns the builder for the settings used for calls to listOperations.
- listOperationsSettings() - Method in class com.google.api.gax.httpjson.longrunning.stub.OperationsStubSettings
-
Returns the object with the settings used for calls to listOperations.
- listOperationsSettings() - Method in class com.google.longrunning.OperationsSettings.Builder
-
Returns the builder for the settings used for calls to listOperations.
- listOperationsSettings() - Method in class com.google.longrunning.OperationsSettings
-
Returns the object with the settings used for calls to listOperations.
- listOperationsSettings() - Method in class com.google.longrunning.stub.OperationsStubSettings.Builder
-
Returns the builder for the settings used for calls to listOperations.
- listOperationsSettings() - Method in class com.google.longrunning.stub.OperationsStubSettings
-
Returns the object with the settings used for calls to listOperations.
- LOCAL_ABORTED_STATUS_CODE - Static variable in exception com.google.api.gax.rpc.WatchdogTimeoutException
- LongRunning - com.google.api.gax.tracing.ApiTracerFactory.OperationType
- longRunningClient() - Method in class com.google.api.gax.httpjson.longrunning.stub.HttpJsonOperationsStub
- longRunningClient() - Method in class com.google.api.gax.httpjson.longrunning.stub.OperationsStub
- LongRunningClient - Interface in com.google.api.gax.rpc
-
Implementation-agnostic interface for managing long-running operations.
- longRunningOperation(UnaryCallable<RequestT, OperationSnapshot>, OperationCallSettings<RequestT, ResponseT, MetadataT>, ClientContext, LongRunningClient) - Static method in class com.google.api.gax.rpc.Callables
-
Creates a callable object that represents a long-running operation.
- lroStartFailed(Throwable) - Method in interface com.google.api.gax.tracing.ApiTracer
-
Signals that the initial RPC for the long running operation failed.
- lroStartFailed(Throwable) - Method in class com.google.api.gax.tracing.BaseApiTracer
- lroStartFailed(Throwable) - Method in class com.google.api.gax.tracing.OpencensusTracer
-
Signals that the initial RPC for the long running operation failed.
- lroStartSucceeded() - Method in interface com.google.api.gax.tracing.ApiTracer
-
Signals that the initial RPC successfully started the long running operation.
- lroStartSucceeded() - Method in class com.google.api.gax.tracing.BaseApiTracer
- lroStartSucceeded() - Method in class com.google.api.gax.tracing.OpencensusTracer
-
Signals that the initial RPC successfully started the long running operation.
M
- ManagedHttpJsonChannel - Class in com.google.api.gax.httpjson
-
Implementation of HttpJsonChannel which can issue http-json calls.
- ManagedHttpJsonChannel() - Constructor for class com.google.api.gax.httpjson.ManagedHttpJsonChannel
- ManagedHttpJsonChannel.Builder - Class in com.google.api.gax.httpjson
- MaxOutstandingElementCountReachedException(long) - Constructor for exception com.google.api.gax.batching.FlowController.MaxOutstandingElementCountReachedException
- MaxOutstandingRequestBytesReachedException(long) - Constructor for exception com.google.api.gax.batching.FlowController.MaxOutstandingRequestBytesReachedException
- merge(B, B) - Method in interface com.google.api.gax.batching.BatchMerger
- merge(HttpJsonCallOptions) - Method in class com.google.api.gax.httpjson.HttpJsonCallOptions
- merge(RetrySettings.Builder) - Method in class com.google.api.gax.retrying.RetrySettings.Builder
- merge(ApiCallContext) - Method in class com.google.api.gax.grpc.GrpcCallContext
- merge(ApiCallContext) - Method in class com.google.api.gax.httpjson.HttpJsonCallContext
- merge(ApiCallContext) - Method in interface com.google.api.gax.rpc.ApiCallContext
-
For any values in
inputCallContext
that are not null, override the corresponding values in the present instance. - merge(Batch<RequestT, ResponseT>) - Method in class com.google.api.gax.rpc.Batch
-
Merge the given batch into this batch.
- merge(ApiCallContextOptions) - Method in class com.google.api.gax.rpc.internal.ApiCallContextOptions
-
Merge new options into existing ones.
- mergeHeaders(Map<String, List<String>>, Map<String, List<String>>) - Static method in class com.google.api.gax.rpc.internal.Headers
- MtlsProvider - Class in com.google.api.gax.rpc.mtls
-
Provider class for mutual TLS.
- MtlsProvider() - Constructor for class com.google.api.gax.rpc.mtls.MtlsProvider
- MtlsProvider.MtlsEndpointUsagePolicy - Enum in com.google.api.gax.rpc.mtls
-
The policy for mutual TLS endpoint usage.
N
- NativeImageUtils - Class in com.google.api.gax.nativeimage
-
Internal class offering helper methods for registering methods/classes for reflection.
- needsCheckInterval() - Method in class com.google.api.gax.rpc.FixedWatchdogProvider
- needsCheckInterval() - Method in class com.google.api.gax.rpc.InstantiatingWatchdogProvider
- needsCheckInterval() - Method in interface com.google.api.gax.rpc.WatchdogProvider
- needsClock() - Method in class com.google.api.gax.rpc.FixedWatchdogProvider
- needsClock() - Method in class com.google.api.gax.rpc.InstantiatingWatchdogProvider
- needsClock() - Method in interface com.google.api.gax.rpc.WatchdogProvider
- needsCredentials() - Method in class com.google.api.gax.grpc.InstantiatingGrpcChannelProvider
- needsCredentials() - Method in class com.google.api.gax.httpjson.InstantiatingHttpJsonChannelProvider
- needsCredentials() - Method in class com.google.api.gax.rpc.FixedTransportChannelProvider
- needsCredentials() - Method in interface com.google.api.gax.rpc.TransportChannelProvider
-
True if credentials are needed before channel creation.
- needsEndpoint() - Method in class com.google.api.gax.grpc.InstantiatingGrpcChannelProvider
- needsEndpoint() - Method in class com.google.api.gax.httpjson.InstantiatingHttpJsonChannelProvider
- needsEndpoint() - Method in class com.google.api.gax.rpc.FixedTransportChannelProvider
- needsEndpoint() - Method in interface com.google.api.gax.rpc.TransportChannelProvider
-
True if the TransportProvider has no endpoint set.
- needsExecutor() - Method in class com.google.api.gax.grpc.InstantiatingGrpcChannelProvider
-
Deprecated.If executor is not set, this channel provider will create channels with default grpc executor.
- needsExecutor() - Method in class com.google.api.gax.httpjson.InstantiatingHttpJsonChannelProvider
-
Deprecated.If executor is not set, this channel provider will create channels with default executor defined in
ManagedHttpJsonChannel
. - needsExecutor() - Method in class com.google.api.gax.rpc.FixedTransportChannelProvider
- needsExecutor() - Method in class com.google.api.gax.rpc.FixedWatchdogProvider
- needsExecutor() - Method in class com.google.api.gax.rpc.InstantiatingWatchdogProvider
- needsExecutor() - Method in interface com.google.api.gax.rpc.TransportChannelProvider
-
Deprecated.Channel providers will have default executors if they need one.
- needsExecutor() - Method in interface com.google.api.gax.rpc.WatchdogProvider
- needsHeaders() - Method in class com.google.api.gax.grpc.InstantiatingGrpcChannelProvider
- needsHeaders() - Method in class com.google.api.gax.httpjson.InstantiatingHttpJsonChannelProvider
- needsHeaders() - Method in class com.google.api.gax.rpc.FixedTransportChannelProvider
- needsHeaders() - Method in interface com.google.api.gax.rpc.TransportChannelProvider
-
True if the TransportProvider has no headers provided.
- NEVER - com.google.api.gax.rpc.mtls.MtlsProvider.MtlsEndpointUsagePolicy
- newBuilder() - Static method in class com.google.api.gax.batching.BatchingSettings
-
Get a new builder.
- newBuilder() - Static method in class com.google.api.gax.batching.DynamicFlowControlSettings
- newBuilder() - Static method in class com.google.api.gax.batching.FlowControlSettings
- newBuilder() - Static method in class com.google.api.gax.batching.ThresholdBatcher
-
Get a new builder for a ThresholdBatcher.
- newBuilder() - Static method in class com.google.api.gax.core.GoogleCredentialsProvider
- newBuilder() - Static method in class com.google.api.gax.core.InstantiatingExecutorProvider
- newBuilder() - Static method in class com.google.api.gax.grpc.GrpcCallSettings
- newBuilder() - Static method in class com.google.api.gax.grpc.GrpcTransportChannel
- newBuilder() - Static method in class com.google.api.gax.grpc.InstantiatingGrpcChannelProvider
- newBuilder() - Static method in class com.google.api.gax.httpjson.ApiMethodDescriptor
- newBuilder() - Static method in class com.google.api.gax.httpjson.HttpJsonCallOptions
- newBuilder() - Static method in class com.google.api.gax.httpjson.HttpJsonCallSettings
- newBuilder() - Static method in class com.google.api.gax.httpjson.HttpJsonMetadata
- newBuilder() - Static method in class com.google.api.gax.httpjson.HttpJsonOperationSnapshot
- newBuilder() - Static method in class com.google.api.gax.httpjson.HttpJsonTransportChannel
- newBuilder() - Static method in class com.google.api.gax.httpjson.InstantiatingHttpJsonChannelProvider
- newBuilder() - Static method in class com.google.api.gax.httpjson.longrunning.OperationsSettings
-
Returns a new builder for this class.
- newBuilder() - Static method in class com.google.api.gax.httpjson.longrunning.stub.OperationsStubSettings
-
Returns a new builder for this class.
- newBuilder() - Static method in class com.google.api.gax.httpjson.ManagedHttpJsonChannel
- newBuilder() - Static method in class com.google.api.gax.httpjson.ProtoMessageRequestFormatter
- newBuilder() - Static method in class com.google.api.gax.httpjson.ProtoMessageResponseParser
- newBuilder() - Static method in class com.google.api.gax.retrying.RetrySettings
- newBuilder() - Static method in class com.google.api.gax.retrying.TimedAttemptSettings
- newBuilder() - Static method in class com.google.api.gax.rpc.ApiClientHeaderProvider
- newBuilder() - Static method in class com.google.api.gax.rpc.ClientContext
- newBuilder() - Static method in class com.google.api.gax.rpc.OperationCallSettings
-
Create a new builder which can construct an instance of OperationCallSettings.
- newBuilder() - Static method in class com.google.api.gax.rpc.ServerStreamingCallSettings
- newBuilder() - Static method in class com.google.api.gax.rpc.StreamingCallSettings
- newBuilder() - Static method in class com.google.longrunning.OperationsSettings
-
Returns a new builder for this class.
- newBuilder() - Static method in class com.google.longrunning.stub.OperationsStubSettings
-
Returns a new builder for this class.
- newBuilder(BatchingDescriptor<ElementT, ElementResultT, RequestT, ResponseT>) - Static method in class com.google.api.gax.batching.BatchingCallSettings
-
Please use
BatchingCallSettings.toBuilder()
to override settings values. - newBuilder(BatchingDescriptor<RequestT, ResponseT>) - Static method in class com.google.api.gax.rpc.BatchingCallSettings
- newBuilder(ClientContext) - Static method in class com.google.api.gax.httpjson.longrunning.OperationsSettings
-
Returns a new builder for this class.
- newBuilder(ClientContext) - Static method in class com.google.api.gax.httpjson.longrunning.stub.OperationsStubSettings
-
Returns a new builder for this class.
- newBuilder(ClientContext) - Static method in class com.google.longrunning.OperationsSettings
-
Returns a new builder for this class.
- newBuilder(ClientContext) - Static method in class com.google.longrunning.stub.OperationsStubSettings
-
Returns a new builder for this class.
- newBuilder(PagedListResponseFactory<RequestT, ResponseT, PagedListResponseT>) - Static method in class com.google.api.gax.rpc.PagedCallSettings
- newCall(ApiMethodDescriptor<RequestT, ResponseT>, HttpJsonCallOptions) - Method in interface com.google.api.gax.httpjson.HttpJsonChannel
- newCall(ApiMethodDescriptor<RequestT, ResponseT>, HttpJsonCallOptions) - Method in class com.google.api.gax.httpjson.ManagedHttpJsonChannel
- newRequestBuilder(RequestT) - Method in interface com.google.api.gax.batching.BatchingDescriptor
-
Creates a new wrapper for the underlying request builder.
- newTracer(ApiTracer, SpanName, ApiTracerFactory.OperationType) - Method in interface com.google.api.gax.tracing.ApiTracerFactory
-
Create a new
ApiTracer
that will be a child of the current context. - newTracer(ApiTracer, SpanName, ApiTracerFactory.OperationType) - Method in class com.google.api.gax.tracing.BaseApiTracerFactory
-
Create a new
ApiTracer
that will be a child of the current context. - newTracer(ApiTracer, SpanName, ApiTracerFactory.OperationType) - Method in class com.google.api.gax.tracing.OpencensusTracerFactory
-
Create a new
ApiTracer
that will be a child of the current context. - newUnaryCallSettingsBuilder() - Static method in class com.google.api.gax.rpc.UnaryCallSettings
- nextRandomLong(long) - Method in class com.google.api.gax.retrying.ExponentialRetryAlgorithm
- NoCredentialsProvider - Class in com.google.api.gax.core
-
NoCredentialsProvider is a CredentialsProvider which always returns null.
- NoCredentialsProvider() - Constructor for class com.google.api.gax.core.NoCredentialsProvider
- NoHeaderProvider - Class in com.google.api.gax.rpc
-
Implementation of HeaderProvider that provides empty headers.
- NoHeaderProvider() - Constructor for class com.google.api.gax.rpc.NoHeaderProvider
- NonCancellableFuture<ResponseT> - Class in com.google.api.gax.retrying
-
A future which cannot be cancelled from the external package.
- NonCancellableFuture() - Constructor for class com.google.api.gax.retrying.NonCancellableFuture
- NOT_FOUND - com.google.api.gax.rpc.StatusCode.Code
- NotFoundException - Exception in com.google.api.gax.rpc
-
Exception thrown when some requested entity (e.g., file or directory) was not found.
- NotFoundException(String, Throwable, StatusCode, boolean) - Constructor for exception com.google.api.gax.rpc.NotFoundException
- NotFoundException(Throwable, StatusCode, boolean) - Constructor for exception com.google.api.gax.rpc.NotFoundException
- NotFoundException(Throwable, StatusCode, boolean, ErrorDetails) - Constructor for exception com.google.api.gax.rpc.NotFoundException
- nullToSelf(ApiCallContext) - Method in class com.google.api.gax.grpc.GrpcCallContext
-
Returns inputContext cast to
GrpcCallContext
, or an emptyGrpcCallContext
if inputContext is null. - nullToSelf(ApiCallContext) - Method in class com.google.api.gax.httpjson.HttpJsonCallContext
-
Returns inputContext cast to
HttpJsonCallContext
, or an emptyHttpJsonCallContext
if inputContext is null. - nullToSelf(ApiCallContext) - Method in interface com.google.api.gax.rpc.ApiCallContext
-
If inputContext is not null, returns it; if it is null, returns the present instance.
- NumericThreshold<E> - Class in com.google.api.gax.batching
-
A threshold which accumulates a count based on the provided ElementCounter.
- NumericThreshold(long, ElementCounter<E>) - Constructor for class com.google.api.gax.batching.NumericThreshold
-
Constructs a NumericThreshold.
O
- of(int) - Static method in class com.google.api.gax.httpjson.HttpJsonStatusCode
-
Creates a new instance with the given status code.
- of(HttpJsonChannel, HttpJsonCallOptions) - Static method in class com.google.api.gax.httpjson.HttpJsonCallContext
- of(StatusCode.Code) - Static method in class com.google.api.gax.httpjson.HttpJsonStatusCode
- of(Code) - Static method in class com.google.api.gax.httpjson.HttpJsonStatusCode
- of(Channel, CallOptions) - Static method in class com.google.api.gax.grpc.GrpcCallContext
-
Returns an instance with the given channel and
CallOptions
. - of(Status.Code) - Static method in class com.google.api.gax.grpc.GrpcStatusCode
-
Creates a new instance with the given
Status.Code
. - of(String, String) - Static method in class com.google.api.gax.tracing.SpanName
-
Creates a new instance of the name.
- OK - com.google.api.gax.rpc.StatusCode.Code
- onClose(int, HttpJsonMetadata) - Method in class com.google.api.gax.httpjson.ForwardingHttpJsonClientCallListener
- onClose(int, HttpJsonMetadata) - Method in class com.google.api.gax.httpjson.HttpJsonClientCall.Listener
-
The ClientCall has been closed.
- onComplete() - Method in interface com.google.api.gax.rpc.ResponseObserver
-
Receives a notification of successful stream completion.
- onComplete() - Method in class com.google.api.gax.rpc.StateCheckingResponseObserver
-
Receives a notification of successful stream completion.
- onCompleted() - Method in interface com.google.api.gax.rpc.ApiStreamObserver
-
Receives a notification of successful stream completion.
- onCompleteImpl() - Method in class com.google.api.gax.rpc.StateCheckingResponseObserver
- onError(Throwable) - Method in interface com.google.api.gax.rpc.ApiStreamObserver
-
Receives a terminating error from the stream.
- onError(Throwable) - Method in interface com.google.api.gax.rpc.ResponseObserver
-
Receives a terminating error from the stream.
- onError(Throwable) - Method in class com.google.api.gax.rpc.StateCheckingResponseObserver
-
Receives a terminating error from the stream.
- onErrorImpl(Throwable) - Method in class com.google.api.gax.rpc.StateCheckingResponseObserver
- onHeaders(HttpJsonMetadata) - Method in class com.google.api.gax.httpjson.ForwardingHttpJsonClientCallListener
- onHeaders(HttpJsonMetadata) - Method in class com.google.api.gax.httpjson.HttpJsonClientCall.Listener
-
The response headers have been received.
- onHeaders(Metadata) - Method in class com.google.api.gax.grpc.GrpcResponseMetadata
- onHeaders(Metadata) - Method in interface com.google.api.gax.grpc.ResponseMetadataHandler
-
Handle the headers returned by an RPC.
- onMessage(ResponseT) - Method in class com.google.api.gax.httpjson.ForwardingHttpJsonClientCallListener
- onMessage(T) - Method in class com.google.api.gax.httpjson.HttpJsonClientCall.Listener
-
A response message has been received.
- onNext(V) - Method in interface com.google.api.gax.rpc.ApiStreamObserver
-
Receives a value from the stream.
- onReady(ClientStream<V>) - Method in interface com.google.api.gax.rpc.ClientStreamReadyObserver
- onResponse(V) - Method in interface com.google.api.gax.rpc.ResponseObserver
-
Receives a value from the stream.
- onResponse(V) - Method in class com.google.api.gax.rpc.StateCheckingResponseObserver
-
Receives a value from the stream.
- onResponseImpl(V) - Method in class com.google.api.gax.rpc.StateCheckingResponseObserver
- onStart(StreamController) - Method in interface com.google.api.gax.rpc.ResponseObserver
-
Called before the stream is started.
- onStart(StreamController) - Method in class com.google.api.gax.rpc.StateCheckingResponseObserver
-
Called before the stream is started.
- onStartImpl(StreamController) - Method in class com.google.api.gax.rpc.StateCheckingResponseObserver
- onTrailers(Metadata) - Method in class com.google.api.gax.grpc.GrpcResponseMetadata
- onTrailers(Metadata) - Method in interface com.google.api.gax.grpc.ResponseMetadataHandler
-
Handle the trailers returned by an RPC.
- OpencensusTracer - Class in com.google.api.gax.tracing
-
Implementation of
ApiTracer
that uses OpenCensus. - OpencensusTracerFactory - Class in com.google.api.gax.tracing
-
A
ApiTracerFactory
to build instances ofOpencensusTracer
. - OpencensusTracerFactory() - Constructor for class com.google.api.gax.tracing.OpencensusTracerFactory
-
Instantiates a new instance capturing the
Tracer
inTracing.getTracer
. - OpencensusTracerFactory(Map<String, String>) - Constructor for class com.google.api.gax.tracing.OpencensusTracerFactory
-
Instantiates a new instance capturing the
Tracer
inTracing.getTracer
. - OperationCallable<RequestT,ResponseT,MetadataT> - Class in com.google.api.gax.rpc
-
An OperationCallable is an immutable object which is capable of initiating RPC calls to long-running API methods and returning an
OperationFuture
to manage the polling of the Operation and getting the response. - OperationCallable() - Constructor for class com.google.api.gax.rpc.OperationCallable
- OperationCallSettings<RequestT,ResponseT,MetadataT> - Class in com.google.api.gax.rpc
-
A settings class to configure an
OperationCallable
for calls to initiate, resume, and cancel a long-running operation. - OperationCallSettings.Builder<RequestT,ResponseT,MetadataT> - Class in com.google.api.gax.rpc
- operationCancelled() - Method in interface com.google.api.gax.tracing.ApiTracer
-
Signals that the operation was cancelled by the user.
- operationCancelled() - Method in class com.google.api.gax.tracing.BaseApiTracer
- operationCancelled() - Method in class com.google.api.gax.tracing.OpencensusTracer
-
Signals that the operation was cancelled by the user.
- operationFailed(Throwable) - Method in interface com.google.api.gax.tracing.ApiTracer
-
Signals that the overall operation has failed and no further attempts will be made.
- operationFailed(Throwable) - Method in class com.google.api.gax.tracing.BaseApiTracer
- operationFailed(Throwable) - Method in class com.google.api.gax.tracing.OpencensusTracer
-
Signals that the overall operation has failed and no further attempts will be made.
- OperationFuture<ResponseT,MetadataT> - Interface in com.google.api.gax.longrunning
-
An ApiFuture which tracks polling of a service.
- OperationFutureImpl<ResponseT,MetadataT> - Class in com.google.api.gax.longrunning
-
An ApiFuture which tracks polling of a service.
- OperationFutureImpl(RetryingFuture<OperationSnapshot>, ApiFuture<OperationSnapshot>, ApiFunction<OperationSnapshot, ResponseT>, ApiFunction<OperationSnapshot, MetadataT>) - Constructor for class com.google.api.gax.longrunning.OperationFutureImpl
-
Creates a new operation future instance.
- OperationFutureImpl(RetryingFuture<OperationSnapshot>, ApiFuture<OperationSnapshot>, ApiFunction<OperationSnapshot, ResponseT>, ApiFunction<OperationSnapshot, MetadataT>, ApiFunction<Exception, ResponseT>) - Constructor for class com.google.api.gax.longrunning.OperationFutureImpl
- OperationFutures - Class in com.google.api.gax.longrunning
- OperationResponsePollAlgorithm - Class in com.google.api.gax.longrunning
-
Operation polling algorithm, which keeps retrying until
OperationSnapshot.isDone()
is true. - OperationResponsePollAlgorithm() - Constructor for class com.google.api.gax.longrunning.OperationResponsePollAlgorithm
- OperationsClient - Class in com.google.api.gax.httpjson.longrunning
-
Service Description: Manages long-running operations with an API service.
- OperationsClient - Class in com.google.longrunning
-
Service Description: Manages long-running operations with an API service.
- OperationsClient(OperationsSettings) - Constructor for class com.google.api.gax.httpjson.longrunning.OperationsClient
-
Constructs an instance of OperationsClient, using the given settings.
- OperationsClient(OperationsStub) - Constructor for class com.google.api.gax.httpjson.longrunning.OperationsClient
- OperationsClient(OperationsSettings) - Constructor for class com.google.longrunning.OperationsClient
-
Constructs an instance of OperationsClient, using the given settings.
- OperationsClient(OperationsStub) - Constructor for class com.google.longrunning.OperationsClient
- OperationsClient.ListOperationsFixedSizeCollection - Class in com.google.api.gax.httpjson.longrunning
- OperationsClient.ListOperationsFixedSizeCollection - Class in com.google.longrunning
- OperationsClient.ListOperationsPage - Class in com.google.api.gax.httpjson.longrunning
- OperationsClient.ListOperationsPage - Class in com.google.longrunning
- OperationsClient.ListOperationsPagedResponse - Class in com.google.api.gax.httpjson.longrunning
- OperationsClient.ListOperationsPagedResponse - Class in com.google.longrunning
- OperationSnapshot - Interface in com.google.api.gax.longrunning
-
A snapshot of a long-running operation.
- OperationSnapshotFactory<RequestT,OperationT> - Interface in com.google.api.gax.httpjson
-
A factory which creates an
OperationSnapshot
from an initial request message (the one which started a long running operation) and an operation response (which may be either initial request response or the polling request response). - OperationsSettings - Class in com.google.api.gax.httpjson.longrunning
-
Settings class to configure an instance of
OperationsClient
. - OperationsSettings - Class in com.google.longrunning
-
Settings class to configure an instance of
OperationsClient
. - OperationsSettings(OperationsSettings.Builder) - Constructor for class com.google.api.gax.httpjson.longrunning.OperationsSettings
- OperationsSettings(OperationsSettings.Builder) - Constructor for class com.google.longrunning.OperationsSettings
- OperationsSettings.Builder - Class in com.google.api.gax.httpjson.longrunning
-
Builder for OperationsSettings.
- OperationsSettings.Builder - Class in com.google.longrunning
-
Builder for OperationsSettings.
- OperationsStub - Class in com.google.api.gax.httpjson.longrunning.stub
-
Base stub class for the Operations service API.
- OperationsStub - Class in com.google.longrunning.stub
-
Base stub class for Google Long Running Operations API.
- OperationsStub() - Constructor for class com.google.api.gax.httpjson.longrunning.stub.OperationsStub
- OperationsStub() - Constructor for class com.google.longrunning.stub.OperationsStub
- OperationsStubSettings - Class in com.google.api.gax.httpjson.longrunning.stub
-
Settings class to configure an instance of
OperationsStub
. - OperationsStubSettings - Class in com.google.longrunning.stub
-
Settings class to configure an instance of
OperationsStub
. - OperationsStubSettings(OperationsStubSettings.Builder) - Constructor for class com.google.api.gax.httpjson.longrunning.stub.OperationsStubSettings
- OperationsStubSettings(OperationsStubSettings.Builder) - Constructor for class com.google.longrunning.stub.OperationsStubSettings
- OperationsStubSettings.Builder - Class in com.google.api.gax.httpjson.longrunning.stub
-
Builder for OperationsStubSettings.
- OperationsStubSettings.Builder - Class in com.google.longrunning.stub
-
Builder for OperationsStubSettings.
- operationSucceeded() - Method in interface com.google.api.gax.tracing.ApiTracer
-
Signals that the overall operation has finished successfully.
- operationSucceeded() - Method in class com.google.api.gax.tracing.BaseApiTracer
- operationSucceeded() - Method in class com.google.api.gax.tracing.OpencensusTracer
-
Signals that the overall operation has finished successfully.
- OperationTimedPollAlgorithm - Class in com.google.api.gax.longrunning
-
Operation timed polling algorithm, which uses exponential backoff factor for determining when the next polling operation should be executed.
- OUT_OF_RANGE - com.google.api.gax.rpc.StatusCode.Code
- OutOfRangeException - Exception in com.google.api.gax.rpc
-
Exception thrown when the operation was attempted past the valid range.
- OutOfRangeException(String, Throwable, StatusCode, boolean) - Constructor for exception com.google.api.gax.rpc.OutOfRangeException
- OutOfRangeException(Throwable, StatusCode, boolean) - Constructor for exception com.google.api.gax.rpc.OutOfRangeException
- OutOfRangeException(Throwable, StatusCode, boolean, ErrorDetails) - Constructor for exception com.google.api.gax.rpc.OutOfRangeException
P
- Page<ResourceT> - Interface in com.google.api.gax.paging
-
A Page object wraps an API list method response.
- PageContext<RequestT,ResponseT,ResourceT> - Class in com.google.api.gax.rpc
-
The context for a page call.
- PageContext() - Constructor for class com.google.api.gax.rpc.PageContext
- paged(UnaryCallable<RequestT, ResponseT>, PagedCallSettings<RequestT, ResponseT, PagedListResponseT>) - Static method in class com.google.api.gax.rpc.Callables
-
Create a paged callable object that represents a paged API method.
- PagedCallable<RequestT,ResponseT,PagedListResponseT> - Class in com.google.api.gax.rpc
-
A UnaryCallable which provides page streaming functionality for unary calls.
- PagedCallable(UnaryCallable<RequestT, ResponseT>, PagedListResponseFactory<RequestT, ResponseT, PagedListResponseT>) - Constructor for class com.google.api.gax.rpc.PagedCallable
- PagedCallSettings<RequestT,ResponseT,PagedListResponseT> - Class in com.google.api.gax.rpc
-
A settings class to configure a
UnaryCallable
for calls to an API method that supports page streaming. - PagedCallSettings.Builder<RequestT,ResponseT,PagedListResponseT> - Class in com.google.api.gax.rpc
- PagedListDescriptor<RequestT,ResponseT,ResourceT> - Interface in com.google.api.gax.rpc
-
An interface which provides the functionality to extract data from requests and inject data into requests for the purposes of page streaming.
- PagedListResponse<ResourceT> - Interface in com.google.api.gax.paging
-
Response for paged results from a list API method
- PagedListResponseFactory<RequestT,ResponseT,PagedListResponseT> - Interface in com.google.api.gax.rpc
-
Interface for constructing futures which return PagedListResponse objects.
- Pages - Class in com.google.api.gax.paging
-
Utility class for
Page
s. - parse(InputStream) - Method in interface com.google.api.gax.httpjson.HttpResponseParser
-
Parse the http body content JSON stream into the MessageFormatT.
- parse(InputStream) - Method in class com.google.api.gax.httpjson.ProtoMessageResponseParser
- parse(InputStream, TypeRegistry) - Method in interface com.google.api.gax.httpjson.HttpResponseParser
-
Parse the http body content JSON stream into the MessageFormatT.
- parse(InputStream, TypeRegistry) - Method in class com.google.api.gax.httpjson.ProtoMessageResponseParser
- parse(Reader, TypeRegistry) - Method in interface com.google.api.gax.httpjson.HttpResponseParser
-
Parse the http body content JSON reader into the MessageFormatT.
- parse(Reader, TypeRegistry) - Method in class com.google.api.gax.httpjson.ProtoMessageResponseParser
- PartitionKey - Class in com.google.api.gax.batching
- PartitionKey(Object...) - Constructor for class com.google.api.gax.batching.PartitionKey
- peekAttemptResult() - Method in interface com.google.api.gax.retrying.RetryingFuture
-
Returns latest completed attempt result or
null
if the first attempt hasn't completed yet. - peekMetadata() - Method in interface com.google.api.gax.longrunning.OperationFuture
-
Peeks at the metadata of the operation tracked by this
OperationFuture
. - peekMetadata() - Method in class com.google.api.gax.longrunning.OperationFutureImpl
- PERMISSION_DENIED - com.google.api.gax.rpc.StatusCode.Code
- PermissionDeniedException - Exception in com.google.api.gax.rpc
-
Exception thrown when the caller does not have permission to execute the specified operation.
- PermissionDeniedException(String, Throwable, StatusCode, boolean) - Constructor for exception com.google.api.gax.rpc.PermissionDeniedException
- PermissionDeniedException(Throwable, StatusCode, boolean) - Constructor for exception com.google.api.gax.rpc.PermissionDeniedException
- PermissionDeniedException(Throwable, StatusCode, boolean, ErrorDetails) - Constructor for exception com.google.api.gax.rpc.PermissionDeniedException
- PollException - Exception in com.google.api.gax.retrying
-
PollException
is thrown when polling algorithm exceeds total timeout or total number of attempts. - PollException() - Constructor for exception com.google.api.gax.retrying.PollException
-
Constructs a
PollException
with no specified detail message. - PollException(String) - Constructor for exception com.google.api.gax.retrying.PollException
-
Constructs a new poll timeout exception with the specified detail message.
- PollingRequestFactory<RequestT> - Interface in com.google.api.gax.httpjson
-
A factory which creates a subsequent polling request from a compund operation id.
- primeChannel(ManagedChannel) - Method in interface com.google.api.gax.grpc.ChannelPrimer
- processBatch(BatchT) - Method in interface com.google.api.gax.batching.ThresholdBatchReceiver
-
Process the given batch asynchronously.
- processBatch(T) - Method in class com.google.api.gax.batching.AccumulatingBatchReceiver
- processResponse(ResponseT) - Method in class com.google.api.gax.retrying.SimpleStreamResumptionStrategy
- processResponse(ResponseT) - Method in interface com.google.api.gax.retrying.StreamResumptionStrategy
-
Called by the
ServerStreamingAttemptCallable
when a response has been successfully received. - ProtocolBufferParsingException - Exception in com.google.api.gax.rpc
-
Exception thrown when parsing protocol buffer message failed
- ProtocolBufferParsingException(String, Throwable) - Constructor for exception com.google.api.gax.rpc.ProtocolBufferParsingException
- ProtoMessageRequestFormatter<RequestT extends com.google.protobuf.Message> - Class in com.google.api.gax.httpjson
-
Creates parts of a HTTP request from a protobuf message.
- ProtoMessageRequestFormatter.Builder<RequestT extends com.google.protobuf.Message> - Class in com.google.api.gax.httpjson
- ProtoMessageResponseParser<ResponseT extends com.google.protobuf.Message> - Class in com.google.api.gax.httpjson
-
The implementation of
HttpResponseParser
which works with protobuf messages. - ProtoMessageResponseParser.Builder<ResponseT extends com.google.protobuf.Message> - Class in com.google.api.gax.httpjson
- ProtoOperationTransformers - Class in com.google.api.gax.grpc
-
Public for technical reasons; intended for use by generated code.
- ProtoOperationTransformers - Class in com.google.api.gax.httpjson
-
Public for technical reasons; intended for use by generated code.
- ProtoOperationTransformers.MetadataTransformer<MetadataT extends com.google.protobuf.Message> - Class in com.google.api.gax.grpc
- ProtoOperationTransformers.MetadataTransformer<MetadataT extends com.google.protobuf.Message> - Class in com.google.api.gax.httpjson
- ProtoOperationTransformers.ResponseTransformer<ResponseT extends com.google.protobuf.Message> - Class in com.google.api.gax.grpc
- ProtoOperationTransformers.ResponseTransformer<ResponseT extends com.google.protobuf.Message> - Class in com.google.api.gax.httpjson
- ProtoRestSerializer<RequestT extends com.google.protobuf.Message> - Class in com.google.api.gax.httpjson
-
This class serializes/deserializes protobuf
Message
for REST interactions. - pushCurrentBatch() - Method in class com.google.api.gax.batching.ThresholdBatcher
-
Push the current batch to the batch receiver.
- putPathParam(Map<String, String>, String, Object) - Method in class com.google.api.gax.httpjson.ProtoRestSerializer
-
Puts a message field in
fields
map which will be used to populate URL path of a request. - putQueryParam(Map<String, List<String>>, String, Object) - Method in class com.google.api.gax.httpjson.ProtoRestSerializer
-
Puts a message field in
fields
map which will be used to populate query parameters of a request.
Q
- QuotaProjectIdHidingCredentials - Class in com.google.api.gax.rpc.internal
-
QuotaProjectIdHidingCredentials
is intended to be used to wrap aCredentials
to hide quota project id - QuotaProjectIdHidingCredentials(Credentials) - Constructor for class com.google.api.gax.rpc.internal.QuotaProjectIdHidingCredentials
R
- record(int) - Method in class com.google.api.gax.core.Distribution
-
Records a new value.
- refresh() - Method in class com.google.api.gax.rpc.internal.QuotaProjectIdHidingCredentials
- registerClassForReflection(Feature.FeatureAccess, String) - Static method in class com.google.api.gax.nativeimage.NativeImageUtils
-
Registers an entire class for reflection use.
- registerClassHierarchyForReflection(Feature.FeatureAccess, String) - Static method in class com.google.api.gax.nativeimage.NativeImageUtils
-
Registers the transitive class hierarchy of the provided
className
for reflection. - registerConstructorsForReflection(Feature.FeatureAccess, String) - Static method in class com.google.api.gax.nativeimage.NativeImageUtils
-
Registers all constructors of a class for reflection.
- registerForReflectiveInstantiation(Feature.FeatureAccess, String) - Static method in class com.google.api.gax.nativeimage.NativeImageUtils
-
Registers a class for reflective construction via its default constructor.
- registerForUnsafeFieldAccess(Feature.FeatureAccess, String, String...) - Static method in class com.google.api.gax.nativeimage.NativeImageUtils
-
Registers a class for unsafe reflective field access.
- release(long, long) - Method in class com.google.api.gax.batching.FlowController
- release(T) - Method in class com.google.api.gax.batching.BatchingFlowController
- request(int) - Method in class com.google.api.gax.httpjson.ForwardingHttpJsonClientCall
- request(int) - Method in class com.google.api.gax.httpjson.HttpJsonClientCall
-
Requests up to the given number of messages from the call to be delivered to
HttpJsonClientCall.Listener.onMessage(Object)
. - request(int) - Method in interface com.google.api.gax.rpc.StreamController
-
Requests up to the given number of responses from the call to be delivered to
ResponseObserver.onResponse(Object)
. - RequestBuilder<RequestT> - Interface in com.google.api.gax.batching
- RequestParamsBuilder - Class in com.google.api.gax.rpc
-
This builder class builds a request params map that will be used by autogenerated implementation of
RequestParamsExtractor
. - RequestParamsEncoder<RequestT> - Interface in com.google.api.gax.rpc
-
A request params encoder takes a
request
object and encodes some (or all) of its parameters in a string form following specific parameter extraction and string encoding rules, defined by concrete implementations of this interface. - RequestParamsExtractor<RequestT> - Interface in com.google.api.gax.rpc
-
A request params extractor takes a
request
message, extracts specific field values from it, converts them in strings and returns them as key-value pairs, where a key is a request field name and a value is a string representation of a field value. - requestSent() - Method in interface com.google.api.gax.tracing.ApiTracer
-
Adds an annotation that a streaming request has been sent.
- requestSent() - Method in class com.google.api.gax.tracing.BaseApiTracer
- requestSent() - Method in class com.google.api.gax.tracing.OpencensusTracer
-
Adds an annotation that a streaming request has been sent.
- RequestUrlParamsEncoder<RequestT> - Class in com.google.api.gax.rpc
-
The request params encoder, which encodes URL-encoded parameters in one URL parameters string.
- RequestUrlParamsEncoder(RequestParamsExtractor<RequestT>, boolean) - Constructor for class com.google.api.gax.rpc.RequestUrlParamsEncoder
-
Creates the encoder.
- reserve(long, long) - Method in class com.google.api.gax.batching.FlowController
- reserve(T) - Method in class com.google.api.gax.batching.BatchingFlowController
- RESOURCE_EXHAUSTED - com.google.api.gax.rpc.StatusCode.Code
- ResourceCloseException - Exception in com.google.api.gax.core
-
An exception occurs when some background resource is not able to close properly.
- ResourceCloseException(Exception) - Constructor for exception com.google.api.gax.core.ResourceCloseException
- ResourceExhaustedException - Exception in com.google.api.gax.rpc
-
Exception thrown when some resource has been exhausted, perhaps a per-user quota, or perhaps the entire file system is out of space.
- ResourceExhaustedException(String, Throwable, StatusCode, boolean) - Constructor for exception com.google.api.gax.rpc.ResourceExhaustedException
- ResourceExhaustedException(Throwable, StatusCode, boolean) - Constructor for exception com.google.api.gax.rpc.ResourceExhaustedException
- ResourceExhaustedException(Throwable, StatusCode, boolean, ErrorDetails) - Constructor for exception com.google.api.gax.rpc.ResourceExhaustedException
- ResponseMetadataHandler - Interface in com.google.api.gax.grpc
-
An interface to handle metadata returned from an RPC.
- ResponseObserver<V> - Interface in com.google.api.gax.rpc
-
Receives notifications from server-streaming calls.
- responseReceived() - Method in interface com.google.api.gax.tracing.ApiTracer
-
Adds an annotation that a streaming response has been received.
- responseReceived() - Method in class com.google.api.gax.tracing.BaseApiTracer
- responseReceived() - Method in class com.google.api.gax.tracing.OpencensusTracer
-
Adds an annotation that a streaming response has been received.
- RestSerializationException - Exception in com.google.api.gax.httpjson
-
An exception thrown when a protobuf message cannot be serialized/deserialized for REST interactions.
- RestSerializationException(String, Throwable) - Constructor for exception com.google.api.gax.httpjson.RestSerializationException
- RestSerializationException(Throwable) - Constructor for exception com.google.api.gax.httpjson.RestSerializationException
- ResultRetryAlgorithm<ResponseT> - Interface in com.google.api.gax.retrying
-
Same as
ResultRetryAlgorithmWithContext
, but without methods that accept aRetryingContext
. - ResultRetryAlgorithmWithContext<ResponseT> - Interface in com.google.api.gax.retrying
-
A result retry algorithm is responsible for the following operations (based on the response returned by the previous attempt or on the thrown exception): Accepting a task for retry so another attempt will be made.
- resumeFutureCall(String) - Method in class com.google.api.gax.rpc.OperationCallable
-
Creates a new
OperationFuture
to watch an operation that has been initiated previously. - resumeFutureCall(String, ApiCallContext) - Method in class com.google.api.gax.rpc.OperationCallable
-
Creates a new
OperationFuture
to watch an operation that has been initiated previously. - resumeFutureCall(String, ApiCallContext) - Method in class com.google.api.gax.tracing.TracedOperationCallable
-
Wrap the polling logical operations in a single parent trace using a
ApiTracerFactory.OperationType.LongRunning
ApiTracer
. - RetryAlgorithm<ResponseT> - Class in com.google.api.gax.retrying
-
The retry algorithm, which makes decision based either on the thrown exception or the returned response, and the execution time settings of the previous attempt.
- RetryAlgorithm(ResultRetryAlgorithm<ResponseT>, TimedRetryAlgorithm) - Constructor for class com.google.api.gax.retrying.RetryAlgorithm
-
Deprecated.
- RetryAlgorithm(ResultRetryAlgorithmWithContext<ResponseT>, TimedRetryAlgorithmWithContext) - Constructor for class com.google.api.gax.retrying.RetryAlgorithm
-
Creates a new retry algorithm instance, which uses thrown exception or returned response and timed algorithms to make a decision.
- retrying(ServerStreamingCallable<RequestT, ResponseT>, ServerStreamingCallSettings<RequestT, ResponseT>, ClientContext) - Static method in class com.google.api.gax.rpc.Callables
- retrying(UnaryCallable<RequestT, ResponseT>, UnaryCallSettings<?, ?>, ClientContext) - Static method in class com.google.api.gax.rpc.Callables
- RetryingContext - Interface in com.google.api.gax.retrying
-
Context for a retryable operation.
- RetryingExecutor<ResponseT> - Interface in com.google.api.gax.retrying
-
A retrying executor is responsible for the following operations: Creating first attempt
RetryingFuture
, which acts as a facade, hiding from client code the actual execution of scheduled retry attempts. - RetryingExecutorWithContext<ResponseT> - Interface in com.google.api.gax.retrying
-
A
RetryingExecutor
that accepts a per-operation context. - RetryingFuture<ResponseT> - Interface in com.google.api.gax.retrying
-
Represents a retrying future.
- retrySettings() - Method in class com.google.api.gax.rpc.ServerStreamingCallSettings.Builder
-
Returns the underlying
RetrySettings.Builder
, which allows callers to augment the existingRetrySettings
. - retrySettings() - Method in class com.google.api.gax.rpc.UnaryCallSettings.Builder
-
Returns the underlying
RetrySettings.Builder
, which allows callers to augment the existingRetrySettings
. - RetrySettings - Class in com.google.api.gax.retrying
-
Holds the parameters for retry or poll logic with jitter, timeout and exponential backoff.
- RetrySettings() - Constructor for class com.google.api.gax.retrying.RetrySettings
- RetrySettings.Builder - Class in com.google.api.gax.retrying
-
A base builder class for
RetrySettings
. - run() - Method in class com.google.api.gax.rpc.Watchdog
S
- ScheduledRetryingExecutor<ResponseT> - Class in com.google.api.gax.retrying
-
The retry executor which uses
ScheduledExecutorService
to schedule an attempt tasks. - ScheduledRetryingExecutor(RetryAlgorithm<ResponseT>, ScheduledExecutorService) - Constructor for class com.google.api.gax.retrying.ScheduledRetryingExecutor
-
Creates a new scheduled retry executor, which will be using
scheduler
for actual attempts scheduling andretryAlgorithm
for retrying strategy. - self() - Method in class com.google.api.gax.rpc.ClientSettings.Builder
- self() - Method in class com.google.api.gax.rpc.StubSettings.Builder
- send(RequestT) - Method in class com.google.api.gax.rpc.BidiStream
-
Send
req
to the server. - send(RequestT) - Method in interface com.google.api.gax.rpc.ClientStream
-
Sends a request to the server.
- sendMessage(RequestT) - Method in class com.google.api.gax.httpjson.ForwardingHttpJsonClientCall
- sendMessage(RequestT) - Method in class com.google.api.gax.httpjson.HttpJsonClientCall
-
Send a request message to the server.
- sendOutstanding() - Method in interface com.google.api.gax.batching.Batcher
-
Sends accumulated elements asynchronously for batching.
- sendOutstanding() - Method in class com.google.api.gax.batching.BatcherImpl
-
Sends accumulated elements asynchronously for batching.
- sendResult() - Method in class com.google.api.gax.rpc.BatchedRequestIssuer
-
Sends back the result that was stored by either setResponse or setException
- serialize(MessageFormatT) - Method in interface com.google.api.gax.httpjson.HttpResponseParser
-
Serialize an object into an HTTP body, which is written out to output.
- serialize(ResponseT) - Method in class com.google.api.gax.httpjson.ProtoMessageResponseParser
- SERVER_STREAMING - com.google.api.gax.httpjson.ApiMethodDescriptor.MethodType
- ServerStream<V> - Class in com.google.api.gax.rpc
-
A blocking Iterable-style wrapper around server stream responses.
- ServerStreaming - com.google.api.gax.tracing.ApiTracerFactory.OperationType
- ServerStreamingAttemptException - Exception in com.google.api.gax.retrying
-
A wrapper exception thrown by
ServerStreamingAttemptCallable
to communicate additional context to theStreamingRetryAlgorithm
and to pass the original cancellation stack trace toRetryingServerStreamingCallable
. - ServerStreamingAttemptException(Throwable, boolean, boolean) - Constructor for exception com.google.api.gax.retrying.ServerStreamingAttemptException
- serverStreamingCall(RequestT, ApiStreamObserver<ResponseT>) - Method in class com.google.api.gax.rpc.ServerStreamingCallable
-
Deprecated.Please use the
ResponseObserver
variant instead. - serverStreamingCall(RequestT, ApiStreamObserver<ResponseT>, ApiCallContext) - Method in class com.google.api.gax.rpc.ServerStreamingCallable
-
Deprecated.Please use the
ResponseObserver
variant instead. - ServerStreamingCallable<RequestT,ResponseT> - Class in com.google.api.gax.rpc
-
A ServerStreamingCallable is an immutable object which is capable of making RPC calls to server streaming API methods.
- ServerStreamingCallable() - Constructor for class com.google.api.gax.rpc.ServerStreamingCallable
- ServerStreamingCallSettings<RequestT,ResponseT> - Class in com.google.api.gax.rpc
-
A settings class to configure a
ServerStreamingCallable
. - ServerStreamingCallSettings.Builder<RequestT,ResponseT> - Class in com.google.api.gax.rpc
- set(ResponseT) - Method in class com.google.api.gax.rpc.BatchedFuture
- setAdditionalPaths(String...) - Method in class com.google.api.gax.httpjson.ProtoMessageRequestFormatter.Builder
- setAllowNonDefaultServiceAccount(boolean) - Method in class com.google.api.gax.grpc.InstantiatingGrpcChannelProvider.Builder
-
Whether allow non-default service account for DirectPath.
- setApiClientHeaderKey(String) - Method in class com.google.api.gax.rpc.ApiClientHeaderProvider.Builder
- setAttemptCount(int) - Method in class com.google.api.gax.retrying.TimedAttemptSettings.Builder
-
Set the attempt count.
- setAttemptDirectPath(boolean) - Method in class com.google.api.gax.grpc.InstantiatingGrpcChannelProvider.Builder
-
Whether attempt DirectPath.
- setAttemptFuture(ApiFuture<ResponseT>) - Method in interface com.google.api.gax.retrying.RetryingFuture
-
Sets the attempt in a form of a future.
- setBackgroundExecutorProvider(ExecutorProvider) - Method in class com.google.api.gax.rpc.ClientSettings.Builder
-
Sets the ExecutorProvider to use for getting the executor to use for running scheduled API call logic (such as retries and long-running operations).
- setBackgroundExecutorProvider(ExecutorProvider) - Method in class com.google.api.gax.rpc.StubSettings.Builder
-
Sets the executor to use for running scheduled API call logic (such as retries and long-running operations).
- setBackgroundResources(List<BackgroundResource>) - Method in class com.google.api.gax.rpc.ClientContext.Builder
- setBatchingSettings(BatchingSettings) - Method in class com.google.api.gax.batching.BatchingCallSettings.Builder
-
Sets the batching settings with various thresholds.
- setBatchingSettings(BatchingSettings) - Method in class com.google.api.gax.rpc.BatchingCallSettings.Builder
- setBatchMerger(BatchMerger<E>) - Method in class com.google.api.gax.batching.ThresholdBatcher.Builder
-
Set the batch merger for the ThresholdBatcher.
- setChannelConfigurator(ApiFunction<ManagedChannelBuilder, ManagedChannelBuilder>) - Method in class com.google.api.gax.grpc.InstantiatingGrpcChannelProvider.Builder
-
Add a callback that can intercept channel creation.
- setChannelPoolSettings(ChannelPoolSettings) - Method in class com.google.api.gax.grpc.InstantiatingGrpcChannelProvider.Builder
- setChannelPrimer(ChannelPrimer) - Method in class com.google.api.gax.grpc.InstantiatingGrpcChannelProvider.Builder
-
By setting a channelPrimer, the ChannelPool created by the provider will be refreshing ChannelPool.
- setChannelsPerCpu(double) - Method in class com.google.api.gax.grpc.InstantiatingGrpcChannelProvider.Builder
-
Deprecated.
- setChannelsPerCpu(double, int) - Method in class com.google.api.gax.grpc.InstantiatingGrpcChannelProvider.Builder
-
Deprecated.
- setClientLibToken(String, String) - Method in class com.google.api.gax.rpc.ApiClientHeaderProvider.Builder
- setClientRuntimeToken(String) - Method in class com.google.api.gax.rpc.ApiClientHeaderProvider.Builder
- setClock(ApiClock) - Method in class com.google.api.gax.rpc.ClientContext.Builder
- setClock(ApiClock) - Method in class com.google.api.gax.rpc.ClientSettings.Builder
-
Sets the clock to use for retry logic.
- setClock(ApiClock) - Method in class com.google.api.gax.rpc.StubSettings.Builder
-
Sets the clock to use for retry logic.
- setCredentials(Credentials) - Method in class com.google.api.gax.grpc.InstantiatingGrpcChannelProvider.Builder
- setCredentials(Credentials) - Method in class com.google.api.gax.httpjson.HttpJsonCallOptions.Builder
- setCredentials(Credentials) - Method in class com.google.api.gax.rpc.ClientContext.Builder
- setCredentialsProvider(CredentialsProvider) - Method in class com.google.api.gax.rpc.ClientSettings.Builder
-
Sets the CredentialsProvider to use for getting the credentials to make calls with.
- setCredentialsProvider(CredentialsProvider) - Method in class com.google.api.gax.rpc.StubSettings.Builder
-
Sets the CredentialsProvider to use for getting the credentials to make calls with.
- setDeadline(Instant) - Method in class com.google.api.gax.httpjson.HttpJsonCallOptions.Builder
- setDefaultCallContext(ApiCallContext) - Method in class com.google.api.gax.rpc.ClientContext.Builder
- setDefaultInstance(ResponseT) - Method in class com.google.api.gax.httpjson.ProtoMessageResponseParser.Builder
- setDefaultTypeRegistry(TypeRegistry) - Method in class com.google.api.gax.httpjson.ProtoMessageResponseParser.Builder
- setDelayThreshold(Duration) - Method in class com.google.api.gax.batching.BatchingSettings.Builder
-
Set the delay threshold to use for batching.
- setDirectPathServiceConfig(Map<String, ?>) - Method in class com.google.api.gax.grpc.InstantiatingGrpcChannelProvider.Builder
-
Sets a service config for direct path.
- setDone(boolean) - Method in class com.google.api.gax.httpjson.HttpJsonOperationSnapshot.Builder
- setElementCountThreshold(Long) - Method in class com.google.api.gax.batching.BatchingSettings.Builder
-
Set the element count threshold to use for batching.
- setEndpoint(String) - Method in class com.google.api.gax.grpc.InstantiatingGrpcChannelProvider.Builder
-
Sets the endpoint used to reach the service, eg "localhost:8080".
- setEndpoint(String) - Method in class com.google.api.gax.httpjson.InstantiatingHttpJsonChannelProvider.Builder
-
Sets the endpoint used to reach the service, eg "localhost:8080".
- setEndpoint(String) - Method in class com.google.api.gax.httpjson.ManagedHttpJsonChannel.Builder
- setEndpoint(String) - Method in class com.google.api.gax.rpc.ClientContext.Builder
- setEndpoint(String) - Method in class com.google.api.gax.rpc.ClientSettings.Builder
- setEndpoint(String) - Method in class com.google.api.gax.rpc.StubSettings.Builder
- setError(int, String) - Method in class com.google.api.gax.httpjson.HttpJsonOperationSnapshot.Builder
- setException(Throwable) - Method in class com.google.api.gax.rpc.BatchedFuture
- setException(Throwable) - Method in class com.google.api.gax.rpc.BatchedRequestIssuer
-
Set the exception to set on the batched future.
- setExecutor(Executor) - Method in class com.google.api.gax.grpc.InstantiatingGrpcChannelProvider.Builder
-
Sets the Executor for this TransportChannelProvider.
- setExecutor(Executor) - Method in class com.google.api.gax.httpjson.InstantiatingHttpJsonChannelProvider.Builder
-
Sets the Executor for this TransportChannelProvider.
- setExecutor(Executor) - Method in class com.google.api.gax.httpjson.ManagedHttpJsonChannel.Builder
- setExecutor(ScheduledExecutorService) - Method in class com.google.api.gax.batching.ThresholdBatcher.Builder
-
Set the executor for the ThresholdBatcher.
- setExecutor(ScheduledExecutorService) - Method in class com.google.api.gax.rpc.ClientContext.Builder
-
Sets the executor to use for running scheduled API call logic (such as retries and long-running operations).
- setExecutorProvider(ExecutorProvider) - Method in class com.google.api.gax.grpc.InstantiatingGrpcChannelProvider.Builder
-
Deprecated.
- setExecutorProvider(ExecutorProvider) - Method in class com.google.api.gax.httpjson.InstantiatingHttpJsonChannelProvider.Builder
-
Deprecated.
- setExecutorProvider(ExecutorProvider) - Method in class com.google.api.gax.rpc.ClientSettings.Builder
-
Deprecated.Please use
ClientSettings.Builder.setBackgroundExecutorProvider(ExecutorProvider)
for setting executor to use for running scheduled API call logic. To set executor forTransportChannelProvider
, please useTransportChannelProvider.withExecutor(Executor)
instead. - setExecutorProvider(ExecutorProvider) - Method in class com.google.api.gax.rpc.StubSettings.Builder
-
Deprecated.Please use
StubSettings.Builder.setBackgroundExecutorProvider(ExecutorProvider)
for setting executor to use for running scheduled API call logic. To set executor forTransportChannelProvider
, please useTransportChannelProvider.withExecutor(Executor)
instead. - setExecutorThreadCount(int) - Method in class com.google.api.gax.core.InstantiatingExecutorProvider.Builder
- setFirstAttemptStartTimeNanos(long) - Method in class com.google.api.gax.retrying.TimedAttemptSettings.Builder
-
Set the start time of the first attempt.
- setFlowController(BatchingFlowController<E>) - Method in class com.google.api.gax.batching.ThresholdBatcher.Builder
-
Set the flow controller for the ThresholdBatcher.
- setFlowController(FlowController) - Method in class com.google.api.gax.rpc.BatchingCallSettings.Builder
- setFlowControlSettings(FlowControlSettings) - Method in class com.google.api.gax.batching.BatchingSettings.Builder
-
Set the flow control settings to be used.
- setFullMethodName(String) - Method in class com.google.api.gax.httpjson.ApiMethodDescriptor.Builder
- setGeneratedLibToken(String, String) - Method in class com.google.api.gax.rpc.ApiClientHeaderProvider.Builder
- setGlobalSettings(RetrySettings) - Method in class com.google.api.gax.retrying.TimedAttemptSettings.Builder
-
Sets global (attempt-independent) retry settings.
- setHeader(HttpHeaders, String, String) - Static method in class com.google.api.gax.httpjson.HttpHeadersUtils
- setHeaderProvider(HeaderProvider) - Method in class com.google.api.gax.grpc.InstantiatingGrpcChannelProvider.Builder
-
Sets the HeaderProvider for this TransportChannelProvider.
- setHeaderProvider(HeaderProvider) - Method in class com.google.api.gax.httpjson.InstantiatingHttpJsonChannelProvider.Builder
-
Sets the HeaderProvider for this TransportChannelProvider.
- setHeaderProvider(HeaderProvider) - Method in class com.google.api.gax.rpc.ClientSettings.Builder
-
Sets the HeaderProvider for getting custom static headers for http requests.
- setHeaderProvider(HeaderProvider) - Method in class com.google.api.gax.rpc.StubSettings.Builder
-
Sets the HeaderProvider for getting custom static headers for http requests.
- setHeaders(HttpHeaders, Map<String, String>) - Static method in class com.google.api.gax.httpjson.HttpHeadersUtils
- setHeaders(Map<String, String>) - Method in class com.google.api.gax.rpc.ClientContext.Builder
- setHttpMethod(String) - Method in class com.google.api.gax.httpjson.ApiMethodDescriptor.Builder
- setHttpTransport(HttpTransport) - Method in class com.google.api.gax.httpjson.InstantiatingHttpJsonChannelProvider.Builder
-
Sets the HTTP transport to be used.
- setHttpTransport(HttpTransport) - Method in class com.google.api.gax.httpjson.ManagedHttpJsonChannel.Builder
- setIdleTimeout(Duration) - Method in class com.google.api.gax.rpc.ServerStreamingCallSettings.Builder
-
See the class documentation of
ServerStreamingCallSettings
for a description of what theServerStreamingCallSettings.Builder.idleTimeout
does. - setInitialCallSettings(UnaryCallSettings<RequestT, OperationSnapshot>) - Method in class com.google.api.gax.rpc.OperationCallSettings.Builder
-
Set the call settings which are used on the call to initiate the operation.
- setInitialChannelCount(int) - Method in class com.google.api.gax.grpc.ChannelPoolSettings.Builder
- setInitialOutstandingElementCount(Long) - Method in class com.google.api.gax.batching.DynamicFlowControlSettings.Builder
- setInitialOutstandingRequestBytes(Long) - Method in class com.google.api.gax.batching.DynamicFlowControlSettings.Builder
- setInitialRetryDelay(Duration) - Method in class com.google.api.gax.retrying.RetrySettings.Builder
-
InitialRetryDelay controls the delay before the first retry.
- setInitialRpcTimeout(Duration) - Method in class com.google.api.gax.retrying.RetrySettings.Builder
-
InitialRpcTimeout controls the timeout for the initial RPC.
- setInterceptorProvider(GrpcInterceptorProvider) - Method in class com.google.api.gax.grpc.InstantiatingGrpcChannelProvider.Builder
-
Sets the GrpcInterceptorProvider for this TransportChannelProvider.
- setInterceptorProvider(HttpJsonInterceptorProvider) - Method in class com.google.api.gax.httpjson.InstantiatingHttpJsonChannelProvider.Builder
-
Sets the GrpcInterceptorProvider for this TransportChannelProvider.
- setInternalHeaderProvider(HeaderProvider) - Method in class com.google.api.gax.rpc.ClientSettings.Builder
-
Sets the HeaderProvider for getting internal (library-defined) static headers for http requests.
- setInternalHeaderProvider(HeaderProvider) - Method in class com.google.api.gax.rpc.StubSettings.Builder
-
Sets the HeaderProvider for getting internal (library-defined) static headers for http requests.
- setInternalHeaders(Map<String, String>) - Method in class com.google.api.gax.rpc.ClientContext.Builder
- setIsEnabled(Boolean) - Method in class com.google.api.gax.batching.BatchingSettings.Builder
-
Set if the batch should be enabled.
- setJittered(boolean) - Method in class com.google.api.gax.retrying.RetrySettings.Builder
-
Deprecated.Retries always jitter.
- setJvmToken(String) - Method in class com.google.api.gax.rpc.ApiClientHeaderProvider.Builder
- setJwtEnabledScopes(List<String>) - Method in class com.google.api.gax.core.GoogleCredentialsProvider.Builder
-
Sets the scopes that are compatible with JWT tokens.
- setKeepAliveTime(Duration) - Method in class com.google.api.gax.grpc.InstantiatingGrpcChannelProvider.Builder
-
The time without read activity before sending a keepalive ping.
- setKeepAliveTimeout(Duration) - Method in class com.google.api.gax.grpc.InstantiatingGrpcChannelProvider.Builder
-
The time without read activity after sending a keepalive ping.
- setKeepAliveWithoutCalls(Boolean) - Method in class com.google.api.gax.grpc.InstantiatingGrpcChannelProvider.Builder
-
Whether keepalive will be performed when there are no outstanding RPCs.
- setLimitExceededBehavior(FlowController.LimitExceededBehavior) - Method in class com.google.api.gax.batching.DynamicFlowControlSettings.Builder
- setLimitExceededBehavior(FlowController.LimitExceededBehavior) - Method in class com.google.api.gax.batching.FlowControlSettings.Builder
- setLogicalTimeout(Duration) - Method in class com.google.api.gax.retrying.RetrySettings.Builder
-
Configures the timeout settings with the given timeout such that the logical call will take no longer than the given timeout and each RPC attempt will use only the time remaining in the logical call as a timeout.
- setManagedChannel(ManagedHttpJsonChannel) - Method in class com.google.api.gax.httpjson.HttpJsonTransportChannel.Builder
- setManagedChannel(ManagedChannel) - Method in class com.google.api.gax.grpc.GrpcTransportChannel.Builder
- setMaxAttempts(int) - Method in class com.google.api.gax.retrying.RetrySettings.Builder
-
MaxAttempts defines the maximum number of attempts to perform.
- setMaxChannelCount(int) - Method in class com.google.api.gax.grpc.ChannelPoolSettings.Builder
- setMaxDelay(Duration) - Method in class com.google.api.gax.batching.ThresholdBatcher.Builder
-
Set the max delay for a batch.
- setMaxInboundMessageSize(Integer) - Method in class com.google.api.gax.grpc.InstantiatingGrpcChannelProvider.Builder
-
The maximum message size allowed to be received on the channel.
- setMaxInboundMetadataSize(Integer) - Method in class com.google.api.gax.grpc.InstantiatingGrpcChannelProvider.Builder
-
The maximum metadata size allowed to be received on the channel.
- setMaxOutstandingElementCount(Long) - Method in class com.google.api.gax.batching.DynamicFlowControlSettings.Builder
- setMaxOutstandingElementCount(Long) - Method in class com.google.api.gax.batching.FlowControlSettings.Builder
- setMaxOutstandingRequestBytes(Long) - Method in class com.google.api.gax.batching.DynamicFlowControlSettings.Builder
- setMaxOutstandingRequestBytes(Long) - Method in class com.google.api.gax.batching.FlowControlSettings.Builder
- setMaxRetryDelay(Duration) - Method in class com.google.api.gax.retrying.RetrySettings.Builder
-
MaxRetryDelay puts a limit on the value of the retry delay, so that the RetryDelayMultiplier can't increase the retry delay higher than this amount.
- setMaxRpcsPerChannel(int) - Method in class com.google.api.gax.grpc.ChannelPoolSettings.Builder
- setMaxRpcTimeout(Duration) - Method in class com.google.api.gax.retrying.RetrySettings.Builder
-
MaxRpcTimeout puts a limit on the value of the RPC timeout, so that the RpcTimeoutMultiplier can't increase the RPC timeout higher than this amount.
- setMetadata(Object) - Method in class com.google.api.gax.httpjson.HttpJsonOperationSnapshot.Builder
- setMetadataTransformer(ApiFunction<OperationSnapshot, MetadataT>) - Method in class com.google.api.gax.rpc.OperationCallSettings.Builder
- setMethodDescriptor(ApiMethodDescriptor<RequestT, ResponseT>) - Method in class com.google.api.gax.httpjson.HttpJsonCallSettings.Builder
- setMethodDescriptor(MethodDescriptor<RequestT, ResponseT>) - Method in class com.google.api.gax.grpc.GrpcCallSettings.Builder
- setMinChannelCount(int) - Method in class com.google.api.gax.grpc.ChannelPoolSettings.Builder
- setMinOutstandingElementCount(Long) - Method in class com.google.api.gax.batching.DynamicFlowControlSettings.Builder
- setMinOutstandingRequestBytes(Long) - Method in class com.google.api.gax.batching.DynamicFlowControlSettings.Builder
- setMinRpcsPerChannel(int) - Method in class com.google.api.gax.grpc.ChannelPoolSettings.Builder
- setMtlsEndpoint(String) - Method in class com.google.api.gax.rpc.StubSettings.Builder
- setName(String) - Method in class com.google.api.gax.httpjson.HttpJsonOperationSnapshot.Builder
- setOperationSnapshotFactory(OperationSnapshotFactory<RequestT, ResponseT>) - Method in class com.google.api.gax.httpjson.ApiMethodDescriptor.Builder
- setOverallAttemptCount(int) - Method in class com.google.api.gax.retrying.TimedAttemptSettings.Builder
-
Set the overall attempt count.
- setParamsExtractor(RequestParamsExtractor<RequestT>) - Method in class com.google.api.gax.grpc.GrpcCallSettings.Builder
- setPath(String, FieldsExtractor<RequestT, Map<String, String>>) - Method in class com.google.api.gax.httpjson.ProtoMessageRequestFormatter.Builder
- setPollingAlgorithm(TimedRetryAlgorithm) - Method in class com.google.api.gax.rpc.OperationCallSettings.Builder
-
Set the polling algorithm of the operation.
- setPollingRequestFactory(PollingRequestFactory<RequestT>) - Method in class com.google.api.gax.httpjson.ApiMethodDescriptor.Builder
- setPoolSize(int) - Method in class com.google.api.gax.grpc.InstantiatingGrpcChannelProvider.Builder
-
Deprecated.
- setPreemptiveRefreshEnabled(boolean) - Method in class com.google.api.gax.grpc.ChannelPoolSettings.Builder
- setQueryParamsExtractor(FieldsExtractor<RequestT, Map<String, List<String>>>) - Method in class com.google.api.gax.httpjson.ProtoMessageRequestFormatter.Builder
- setQuotaProjectId(String) - Method in class com.google.api.gax.rpc.ClientContext.Builder
- setQuotaProjectId(String) - Method in class com.google.api.gax.rpc.ClientSettings.Builder
- setQuotaProjectId(String) - Method in class com.google.api.gax.rpc.StubSettings.Builder
- setQuotaProjectIdToken(String) - Method in class com.google.api.gax.rpc.ApiClientHeaderProvider.Builder
-
Sets the project ID used for quota and billing purposes.
- setRandomizedRetryDelay(Duration) - Method in class com.google.api.gax.retrying.TimedAttemptSettings.Builder
-
Sets randomized attempt delay.
- setRawErrorMessages(List<Any>) - Method in class com.google.api.gax.rpc.ErrorDetails.Builder
- setReceiver(ThresholdBatchReceiver<E>) - Method in class com.google.api.gax.batching.ThresholdBatcher.Builder
-
Set the threshold batch receiver for the ThresholdBatcher.
- setRequestBodyExtractor(FieldsExtractor<RequestT, String>) - Method in class com.google.api.gax.httpjson.ProtoMessageRequestFormatter.Builder
- setRequestByteThreshold(Long) - Method in class com.google.api.gax.batching.BatchingSettings.Builder
-
Set the request byte threshold to use for batching.
- setRequestFormatter(HttpRequestFormatter<RequestT>) - Method in class com.google.api.gax.httpjson.ApiMethodDescriptor.Builder
- setResourceHeaderKey(String) - Method in class com.google.api.gax.rpc.ApiClientHeaderProvider.Builder
- setResourceToken(String) - Method in class com.google.api.gax.rpc.ApiClientHeaderProvider.Builder
- setResponse(Object) - Method in class com.google.api.gax.httpjson.HttpJsonOperationSnapshot.Builder
- setResponse(ResponseT) - Method in class com.google.api.gax.rpc.BatchedRequestIssuer
-
Set the response to set on the batched future.
- setResponseParser(HttpResponseParser<ResponseT>) - Method in class com.google.api.gax.httpjson.ApiMethodDescriptor.Builder
- setResponseTransformer(ApiFunction<OperationSnapshot, ResponseT>) - Method in class com.google.api.gax.rpc.OperationCallSettings.Builder
- setResumptionStrategy(StreamResumptionStrategy<RequestT, ResponseT>) - Method in class com.google.api.gax.rpc.ServerStreamingCallSettings.Builder
-
See the class documentation of
ServerStreamingCallSettings
for a description of what StreamResumptionStrategy does. - setRetryableCodes(StatusCode.Code...) - Method in class com.google.api.gax.batching.BatchingCallSettings.Builder
-
Sets the rpc failure
code
, for which retries should be performed. - setRetryableCodes(StatusCode.Code...) - Method in class com.google.api.gax.rpc.BatchingCallSettings.Builder
- setRetryableCodes(StatusCode.Code...) - Method in class com.google.api.gax.rpc.PagedCallSettings.Builder
- setRetryableCodes(StatusCode.Code...) - Method in class com.google.api.gax.rpc.ServerStreamingCallSettings.Builder
-
See the class documentation of
ServerStreamingCallSettings
for a description of what retryableCodes do. - setRetryableCodes(StatusCode.Code...) - Method in class com.google.api.gax.rpc.UnaryCallSettings.Builder
-
See the class documentation of
UnaryCallSettings
for a description of what retryable codes do. - setRetryableCodes(Set<StatusCode.Code>) - Method in class com.google.api.gax.batching.BatchingCallSettings.Builder
-
Sets the rpc failure
code
, for which retries should be performed. - setRetryableCodes(Set<StatusCode.Code>) - Method in class com.google.api.gax.rpc.BatchingCallSettings.Builder
- setRetryableCodes(Set<StatusCode.Code>) - Method in class com.google.api.gax.rpc.PagedCallSettings.Builder
- setRetryableCodes(Set<StatusCode.Code>) - Method in class com.google.api.gax.rpc.ServerStreamingCallSettings.Builder
-
See the class documentation of
ServerStreamingCallSettings
for a description of what retryableCodes do. - setRetryableCodes(Set<StatusCode.Code>) - Method in class com.google.api.gax.rpc.UnaryCallSettings.Builder
-
See the class documentation of
UnaryCallSettings
for a description of what retryable codes do. - setRetryDelay(Duration) - Method in class com.google.api.gax.retrying.TimedAttemptSettings.Builder
-
Sets the calculated retry delay.
- setRetryDelayMultiplier(double) - Method in class com.google.api.gax.retrying.RetrySettings.Builder
-
RetryDelayMultiplier controls the change in retry delay.
- setRetrySettings(RetrySettings) - Method in class com.google.api.gax.batching.BatchingCallSettings.Builder
-
Sets the
RetrySettings
values for each retry attempts. - setRetrySettings(RetrySettings) - Method in class com.google.api.gax.rpc.BatchingCallSettings.Builder
- setRetrySettings(RetrySettings) - Method in class com.google.api.gax.rpc.PagedCallSettings.Builder
- setRetrySettings(RetrySettings) - Method in class com.google.api.gax.rpc.ServerStreamingCallSettings.Builder
-
Replaces the
RetrySettings
for the associatedServerStreamingCallable
. - setRetrySettings(RetrySettings) - Method in class com.google.api.gax.rpc.UnaryCallSettings.Builder
-
Replaces the
RetrySettings
for the associatedUnaryCallable
. - setRpcTimeout(Duration) - Method in class com.google.api.gax.retrying.TimedAttemptSettings.Builder
-
Sets rpc timeout used for this attempt.
- setRpcTimeoutMultiplier(double) - Method in class com.google.api.gax.retrying.RetrySettings.Builder
-
See the class documentation of
RetrySettings
for a description of what this value does. - setScopesToApply(List<String>) - Method in class com.google.api.gax.core.GoogleCredentialsProvider.Builder
-
Sets the scopes to apply to the credentials that are acquired from Application Default Credentials, before the credentials are sent to the service.
- setShouldAwaitTrailers(boolean) - Method in class com.google.api.gax.grpc.GrpcCallSettings.Builder
- setSimpleTimeoutNoRetries(Duration) - Method in class com.google.api.gax.rpc.ServerStreamingCallSettings.Builder
-
Disables retries and sets the overall timeout.
- setSimpleTimeoutNoRetries(Duration) - Method in class com.google.api.gax.rpc.UnaryCallSettings.Builder
-
Disables retries and sets the RPC timeout.
- setStreamWatchdog(Watchdog) - Method in class com.google.api.gax.rpc.ClientContext.Builder
- setStreamWatchdogCheckInterval(Duration) - Method in class com.google.api.gax.rpc.ClientContext.Builder
- setStreamWatchdogCheckInterval(Duration) - Method in class com.google.api.gax.rpc.StubSettings.Builder
-
Sets how often the
Watchdog
will check ongoing streaming RPCs. - setStreamWatchdogProvider(WatchdogProvider) - Method in class com.google.api.gax.rpc.StubSettings.Builder
-
Sets the
WatchdogProvider
to use for streaming RPC. - setSwitchToMtlsEndpointAllowed(boolean) - Method in class com.google.api.gax.rpc.StubSettings.Builder
- setThreadFactory(ThreadFactory) - Method in class com.google.api.gax.core.InstantiatingExecutorProvider.Builder
- setThresholds(Collection<BatchingThreshold<E>>) - Method in class com.google.api.gax.batching.ThresholdBatcher.Builder
-
Set the thresholds for the ThresholdBatcher.
- setTotalTimeout(Duration) - Method in class com.google.api.gax.retrying.RetrySettings.Builder
-
TotalTimeout has ultimate control over how long the logic should keep trying the remote call until it gives up completely.
- setTracerFactory(ApiTracerFactory) - Method in class com.google.api.gax.rpc.ClientContext.Builder
-
Set the
ApiTracerFactory
that will be used to generate traces for operations. - setTracerFactory(ApiTracerFactory) - Method in class com.google.api.gax.rpc.StubSettings.Builder
-
Configures the
ApiTracerFactory
that will be used to generate traces. - setTransportChannel(TransportChannel) - Method in class com.google.api.gax.rpc.ClientContext.Builder
- setTransportChannelProvider(TransportChannelProvider) - Method in class com.google.api.gax.rpc.ClientSettings.Builder
-
Sets the TransportProvider to use for getting the transport-specific context to make calls with.
- setTransportChannelProvider(TransportChannelProvider) - Method in class com.google.api.gax.rpc.StubSettings.Builder
-
Sets the TransportProvider to use for getting the transport-specific context to make calls with.
- setTransportToken(String, String) - Method in class com.google.api.gax.rpc.ApiClientHeaderProvider.Builder
- setType(ApiMethodDescriptor.MethodType) - Method in class com.google.api.gax.httpjson.ApiMethodDescriptor.Builder
- setTypeRegistry(TypeRegistry) - Method in class com.google.api.gax.httpjson.HttpJsonCallOptions.Builder
- setTypeRegistry(TypeRegistry) - Method in class com.google.api.gax.httpjson.HttpJsonCallSettings.Builder
- setUseJwtAccessWithScope(boolean) - Method in class com.google.api.gax.core.GoogleCredentialsProvider.Builder
-
Whether self signed JWT with scopes should be used for service account credentials.
- setWatchdogCheckInterval(Duration) - Method in class com.google.api.gax.rpc.ClientSettings.Builder
- setWatchdogProvider(WatchdogProvider) - Method in class com.google.api.gax.rpc.ClientSettings.Builder
- shouldAutoClose() - Method in interface com.google.api.gax.core.ExecutorProvider
-
Indicates whether the executor should be closed by the containing client class.
- shouldAutoClose() - Method in class com.google.api.gax.core.FixedExecutorProvider
- shouldAutoClose() - Method in class com.google.api.gax.core.InstantiatingExecutorProvider
- shouldAutoClose() - Method in class com.google.api.gax.grpc.InstantiatingGrpcChannelProvider
- shouldAutoClose() - Method in class com.google.api.gax.httpjson.InstantiatingHttpJsonChannelProvider
- shouldAutoClose() - Method in class com.google.api.gax.rpc.FixedTransportChannelProvider
- shouldAutoClose() - Method in class com.google.api.gax.rpc.FixedWatchdogProvider
- shouldAutoClose() - Method in class com.google.api.gax.rpc.InstantiatingWatchdogProvider
- shouldAutoClose() - Method in interface com.google.api.gax.rpc.TransportChannelProvider
-
Indicates whether the TransportChannel should be closed by the containing client class.
- shouldAutoClose() - Method in interface com.google.api.gax.rpc.WatchdogProvider
- shouldAwaitTrailers() - Method in class com.google.api.gax.grpc.GrpcCallSettings
- shouldRetry(RetryingContext, TimedAttemptSettings) - Method in class com.google.api.gax.retrying.ExponentialRetryAlgorithm
-
Returns
true
if another attempt should be made, orfalse
otherwise. - shouldRetry(RetryingContext, TimedAttemptSettings) - Method in interface com.google.api.gax.retrying.TimedRetryAlgorithmWithContext
-
Returns
true
if another attempt should be made, orfalse
otherwise. - shouldRetry(RetryingContext, Throwable, ResponseT) - Method in class com.google.api.gax.retrying.BasicResultRetryAlgorithm
-
Returns
true
if an exception was thrown (previousThrowable != null
),false
otherwise. - shouldRetry(RetryingContext, Throwable, ResponseT) - Method in interface com.google.api.gax.retrying.ResultRetryAlgorithmWithContext
-
Returns
true
if another attempt should be made, orfalse
otherwise. - shouldRetry(RetryingContext, Throwable, ResponseT, TimedAttemptSettings) - Method in class com.google.api.gax.retrying.RetryAlgorithm
-
Returns
true
if another attempt should be made, orfalse
otherwise. - shouldRetry(RetryingContext, Throwable, ResponseT, TimedAttemptSettings) - Method in class com.google.api.gax.retrying.StreamingRetryAlgorithm
-
Returns
true
if another attempt should be made, orfalse
otherwise. - shouldRetry(TimedAttemptSettings) - Method in class com.google.api.gax.longrunning.OperationTimedPollAlgorithm
-
Returns
true
if another poll operation should be made or throwsCancellationException
otherwise. - shouldRetry(TimedAttemptSettings) - Method in class com.google.api.gax.retrying.ExponentialPollAlgorithm
-
Returns
true
if another poll operation should be made or throwsPollException
, if either total timeout or total number of attempts is exceeded. - shouldRetry(TimedAttemptSettings) - Method in class com.google.api.gax.retrying.ExponentialRetryAlgorithm
-
Returns
true
if another attempt should be made, orfalse
otherwise. - shouldRetry(TimedAttemptSettings) - Method in interface com.google.api.gax.retrying.TimedRetryAlgorithm
-
Same as
TimedRetryAlgorithmWithContext.shouldRetry(RetryingContext, TimedAttemptSettings)
, but without aRetryingContext
. - shouldRetry(Throwable, OperationSnapshot) - Method in class com.google.api.gax.longrunning.OperationResponsePollAlgorithm
- shouldRetry(Throwable, ResponseT) - Method in class com.google.api.gax.retrying.BasicResultRetryAlgorithm
-
Returns
true
if an exception was thrown (previousThrowable != null
),false
otherwise. - shouldRetry(Throwable, ResponseT) - Method in interface com.google.api.gax.retrying.ResultRetryAlgorithm
-
Same as
ResultRetryAlgorithm.shouldRetry(Throwable, Object)
, but without aRetryingContext
. - shouldRetry(Throwable, ResponseT, TimedAttemptSettings) - Method in class com.google.api.gax.retrying.RetryAlgorithm
-
Deprecated.
- shouldRetry(Throwable, ResponseT, TimedAttemptSettings) - Method in class com.google.api.gax.retrying.StreamingRetryAlgorithm
-
Returns
true
if another attempt should be made, orfalse
otherwise. - shutdown() - Method in interface com.google.api.gax.core.BackgroundResource
-
Initiates an orderly shutdown in which previously submitted work is finished, but no new work will be accepted.
- shutdown() - Method in class com.google.api.gax.core.BackgroundResourceAggregation
- shutdown() - Method in class com.google.api.gax.core.BaseBackgroundResource
- shutdown() - Method in class com.google.api.gax.core.ExecutorAsBackgroundResource
- shutdown() - Method in class com.google.api.gax.grpc.GrpcTransportChannel
- shutdown() - Method in class com.google.api.gax.httpjson.HttpJsonTransportChannel
- shutdown() - Method in class com.google.api.gax.httpjson.longrunning.OperationsClient
- shutdown() - Method in class com.google.api.gax.httpjson.longrunning.stub.HttpJsonOperationsStub
- shutdown() - Method in class com.google.api.gax.httpjson.ManagedHttpJsonChannel
- shutdown() - Method in class com.google.api.gax.rpc.Watchdog
- shutdown() - Method in class com.google.longrunning.OperationsClient
- shutdown() - Method in class com.google.longrunning.stub.GrpcOperationsStub
- shutdownNow() - Method in interface com.google.api.gax.core.BackgroundResource
-
Attempts to stop all actively executing work and halts the processing of waiting work.
- shutdownNow() - Method in class com.google.api.gax.core.BackgroundResourceAggregation
- shutdownNow() - Method in class com.google.api.gax.core.BaseBackgroundResource
- shutdownNow() - Method in class com.google.api.gax.core.ExecutorAsBackgroundResource
- shutdownNow() - Method in class com.google.api.gax.grpc.GrpcTransportChannel
- shutdownNow() - Method in class com.google.api.gax.httpjson.HttpJsonTransportChannel
- shutdownNow() - Method in class com.google.api.gax.httpjson.longrunning.OperationsClient
- shutdownNow() - Method in class com.google.api.gax.httpjson.longrunning.stub.HttpJsonOperationsStub
- shutdownNow() - Method in class com.google.api.gax.httpjson.ManagedHttpJsonChannel
- shutdownNow() - Method in class com.google.api.gax.rpc.Watchdog
- shutdownNow() - Method in class com.google.longrunning.OperationsClient
- shutdownNow() - Method in class com.google.longrunning.stub.GrpcOperationsStub
- SimpleForwardingHttpJsonClientCall(HttpJsonClientCall<RequestT, ResponseT>) - Constructor for class com.google.api.gax.httpjson.ForwardingHttpJsonClientCall.SimpleForwardingHttpJsonClientCall
- SimpleForwardingHttpJsonClientCallListener(HttpJsonClientCall.Listener<ResponseT>) - Constructor for class com.google.api.gax.httpjson.ForwardingHttpJsonClientCallListener.SimpleForwardingHttpJsonClientCallListener
- SimpleStreamResumptionStrategy<RequestT,ResponseT> - Class in com.google.api.gax.retrying
-
Simplest implementation of a
StreamResumptionStrategy
which returns the initial request for unstarted streams. - SimpleStreamResumptionStrategy() - Constructor for class com.google.api.gax.retrying.SimpleStreamResumptionStrategy
- sleep(Duration) - Method in class com.google.api.gax.retrying.DirectRetryingExecutor
-
This method simply calls
Thread.sleep(long)
. - SpanName - Class in com.google.api.gax.tracing
-
A value class to represent the name of the operation in an
ApiTracer
. - SpanName() - Constructor for class com.google.api.gax.tracing.SpanName
- splitCall(ResponseObserver<ResponseT>) - Method in class com.google.api.gax.rpc.BidiStreamingCallable
-
Send requests to the server and listens to responses.
- splitCall(ResponseObserver<ResponseT>, ApiCallContext) - Method in class com.google.api.gax.rpc.BidiStreamingCallable
-
Send requests to the server and listens to responses.
- splitException(Throwable, Collection<? extends BatchedRequestIssuer<ResponseT>>) - Method in interface com.google.api.gax.rpc.BatchingDescriptor
-
Splits the exception that resulted from a batched call into an individual setException call on each RequestIssuer.
- splitException(Throwable, List<BatchEntry<ElementT, ElementResultT>>) - Method in interface com.google.api.gax.batching.BatchingDescriptor
-
Unpacks the batch response error into individual element errors.
- splitResponse(ResponseT, Collection<? extends BatchedRequestIssuer<ResponseT>>) - Method in interface com.google.api.gax.rpc.BatchingDescriptor
-
Splits the result from a batched call into an individual setResponse call on each RequestIssuer.
- splitResponse(ResponseT, List<BatchEntry<ElementT, ElementResultT>>) - Method in interface com.google.api.gax.batching.BatchingDescriptor
-
Unpacks the batch response into individual elements results.
- start(HttpJsonClientCall.Listener<ResponseT>, HttpJsonMetadata) - Method in class com.google.api.gax.httpjson.ForwardingHttpJsonClientCall
- start(HttpJsonClientCall.Listener<ResponseT>, HttpJsonMetadata) - Method in class com.google.api.gax.httpjson.HttpJsonClientCall
-
Start a call, using
responseListener
for processing response messages. - StateCheckingResponseObserver<V> - Class in com.google.api.gax.rpc
-
Base implementation of
ResponseObserver
that performs state sanity checks. - StateCheckingResponseObserver() - Constructor for class com.google.api.gax.rpc.StateCheckingResponseObserver
- staticallySized(int) - Static method in class com.google.api.gax.grpc.ChannelPoolSettings
- StatusCode - Interface in com.google.api.gax.rpc
-
Transport-specific status code.
- StatusCode.Code - Enum in com.google.api.gax.rpc
- StreamController - Interface in com.google.api.gax.rpc
-
Allows the implementer of
ResponseObserver
to control the flow of responses. - StreamingCallSettings<RequestT,ResponseT> - Class in com.google.api.gax.rpc
-
A settings class to configure a streaming callable object for calls to a streaming API method.
- StreamingCallSettings() - Constructor for class com.google.api.gax.rpc.StreamingCallSettings
- StreamingCallSettings.Builder<RequestT,ResponseT> - Class in com.google.api.gax.rpc
- StreamingRetryAlgorithm<ResponseT> - Class in com.google.api.gax.retrying
-
The streaming retry algorithm, which makes decision based either on the thrown exception and the execution time settings of the previous attempt.
- StreamingRetryAlgorithm(ResultRetryAlgorithm<ResponseT>, TimedRetryAlgorithm) - Constructor for class com.google.api.gax.retrying.StreamingRetryAlgorithm
-
Deprecated.
- StreamingRetryAlgorithm(ResultRetryAlgorithmWithContext<ResponseT>, TimedRetryAlgorithmWithContext) - Constructor for class com.google.api.gax.retrying.StreamingRetryAlgorithm
-
Creates a
StreamingRetryAlgorithm
that will use the settings (if any) in theRetryingContext
that is passed in to the retrying methods. - StreamResumptionStrategy<RequestT,ResponseT> - Interface in com.google.api.gax.retrying
-
This is part of the server streaming retry api.
- StubSettings<SettingsT extends StubSettings<SettingsT>> - Class in com.google.api.gax.rpc
-
A base settings class to configure a client stub class.
- StubSettings(StubSettings.Builder) - Constructor for class com.google.api.gax.rpc.StubSettings
-
Constructs an instance of StubSettings.
- StubSettings.Builder<SettingsT extends StubSettings<SettingsT>,B extends StubSettings.Builder<SettingsT,B>> - Class in com.google.api.gax.rpc
- submit(RetryingFuture<ResponseT>) - Method in class com.google.api.gax.retrying.DirectRetryingExecutor
-
Submits an attempt for execution in the current thread, causing the current thread to sleep for the specified by the
RetryingFuture.getAttemptSettings()
amount of time. - submit(RetryingFuture<ResponseT>) - Method in interface com.google.api.gax.retrying.RetryingExecutor
-
Submits an attempt for execution.
- submit(RetryingFuture<ResponseT>) - Method in class com.google.api.gax.retrying.ScheduledRetryingExecutor
-
Submits an attempt for execution in a different thread.
T
- ThresholdBatcher<E> - Class in com.google.api.gax.batching
-
Queues up elements until either a duration of time has passed or any threshold in a given set of thresholds is breached, and then delivers the elements in a batch to the consumer.
- ThresholdBatcher.Builder<E> - Class in com.google.api.gax.batching
-
Builder for a ThresholdBatcher.
- ThresholdBatchReceiver<BatchT> - Interface in com.google.api.gax.batching
-
Interface representing an object that receives batches from a ThresholdBatcher and takes action on them.
- THROTTLED_TIME_KEY - Static variable in interface com.google.api.gax.batching.Batcher
-
ApiCallContext.Key
for tracking batch total throttled time - ThrowException - com.google.api.gax.batching.FlowController.LimitExceededBehavior
- TimedAttemptSettings - Class in com.google.api.gax.retrying
-
Timed attempt execution settings.
- TimedAttemptSettings() - Constructor for class com.google.api.gax.retrying.TimedAttemptSettings
- TimedAttemptSettings.Builder - Class in com.google.api.gax.retrying
- TimedRetryAlgorithm - Interface in com.google.api.gax.retrying
-
Same as
TimedRetryAlgorithmWithContext
, but without methods that accept aRetryingContext
. - TimedRetryAlgorithmWithContext - Interface in com.google.api.gax.retrying
-
A timed retry algorithm is responsible for the following operations, based on the previous attempt settings and current time: Creating first attempt
TimedAttemptSettings
. - toBody(String, RequestT) - Method in class com.google.api.gax.httpjson.ProtoRestSerializer
-
Serializes a message to a request body in a form of JSON-encoded string.
- toBody(String, RequestT, boolean) - Method in class com.google.api.gax.httpjson.ProtoRestSerializer
-
Serializes a message to a request body in a form of JSON-encoded string.
- toBuilder() - Method in class com.google.api.gax.batching.BatchingCallSettings
-
Get a builder with the same values as this object.
- toBuilder() - Method in class com.google.api.gax.batching.BatchingSettings
-
Get a builder with the same values as this object.
- toBuilder() - Method in class com.google.api.gax.batching.DynamicFlowControlSettings
- toBuilder() - Method in class com.google.api.gax.batching.FlowControlSettings
- toBuilder() - Method in class com.google.api.gax.core.GoogleCredentialsProvider
- toBuilder() - Method in class com.google.api.gax.core.InstantiatingExecutorProvider
- toBuilder() - Method in class com.google.api.gax.grpc.ChannelPoolSettings
- toBuilder() - Method in class com.google.api.gax.grpc.GrpcCallSettings
- toBuilder() - Method in class com.google.api.gax.grpc.InstantiatingGrpcChannelProvider
- toBuilder() - Method in class com.google.api.gax.httpjson.ApiMethodDescriptor
- toBuilder() - Method in class com.google.api.gax.httpjson.HttpJsonCallOptions
- toBuilder() - Method in class com.google.api.gax.httpjson.HttpJsonCallSettings
- toBuilder() - Method in class com.google.api.gax.httpjson.HttpJsonMetadata
- toBuilder() - Method in class com.google.api.gax.httpjson.InstantiatingHttpJsonChannelProvider
- toBuilder() - Method in class com.google.api.gax.httpjson.longrunning.OperationsSettings
-
Returns a builder containing all the values of this settings class.
- toBuilder() - Method in class com.google.api.gax.httpjson.longrunning.stub.OperationsStubSettings
-
Returns a builder containing all the values of this settings class.
- toBuilder() - Method in class com.google.api.gax.httpjson.ProtoMessageRequestFormatter
- toBuilder() - Method in class com.google.api.gax.retrying.RetrySettings
- toBuilder() - Method in class com.google.api.gax.retrying.TimedAttemptSettings
- toBuilder() - Method in class com.google.api.gax.rpc.BatchingCallSettings
- toBuilder() - Method in class com.google.api.gax.rpc.ClientContext
- toBuilder() - Method in class com.google.api.gax.rpc.ClientSettings
- toBuilder() - Method in class com.google.api.gax.rpc.OperationCallSettings
- toBuilder() - Method in class com.google.api.gax.rpc.PagedCallSettings
- toBuilder() - Method in class com.google.api.gax.rpc.ServerStreamingCallSettings
- toBuilder() - Method in class com.google.api.gax.rpc.StreamingCallSettings
- toBuilder() - Method in class com.google.api.gax.rpc.StubSettings
- toBuilder() - Method in class com.google.api.gax.rpc.UnaryCallSettings
- toBuilder() - Method in class com.google.longrunning.OperationsSettings
-
Returns a builder containing all the values of this settings class.
- toBuilder() - Method in class com.google.longrunning.stub.OperationsStubSettings
-
Returns a builder containing all the values of this settings class.
- toString() - Method in class com.google.api.gax.batching.BatchingCallSettings
- toString() - Method in exception com.google.api.gax.batching.FlowController.MaxOutstandingElementCountReachedException
- toString() - Method in exception com.google.api.gax.batching.FlowController.MaxOutstandingRequestBytesReachedException
- toString() - Method in class com.google.api.gax.core.Distribution
- toString() - Method in class com.google.api.gax.httpjson.HttpJsonStatusCode
- toString() - Method in class com.google.api.gax.rpc.BatchingCallSettings
- toString() - Method in class com.google.api.gax.rpc.ClientSettings.Builder
- toString() - Method in class com.google.api.gax.rpc.ClientSettings
- toString() - Method in class com.google.api.gax.rpc.PagedCallable
- toString() - Method in class com.google.api.gax.rpc.ServerStreamingCallSettings
- toString() - Method in class com.google.api.gax.rpc.StubSettings.Builder
- toString() - Method in class com.google.api.gax.rpc.StubSettings
- toString() - Method in class com.google.api.gax.rpc.UnaryCallSettings
- toString() - Method in class com.google.api.gax.tracing.SpanName
- TracedBatchingCallable<RequestT,ResponseT> - Class in com.google.api.gax.tracing
-
This callable wraps a batching callable chain in a
ApiTracer
. - TracedBatchingCallable(UnaryCallable<RequestT, ResponseT>, ApiTracerFactory, SpanName, BatchingDescriptor<RequestT, ResponseT>) - Constructor for class com.google.api.gax.tracing.TracedBatchingCallable
- TracedBidiCallable<RequestT,ResponseT> - Class in com.google.api.gax.tracing
-
A wrapper callable that will wrap a callable chain in a trace.
- TracedBidiCallable(BidiStreamingCallable<RequestT, ResponseT>, ApiTracerFactory, SpanName) - Constructor for class com.google.api.gax.tracing.TracedBidiCallable
- TracedClientStreamingCallable<RequestT,ResponseT> - Class in com.google.api.gax.tracing
-
A wrapper callable that will wrap a callable chain in a trace.
- TracedClientStreamingCallable(ClientStreamingCallable<RequestT, ResponseT>, ApiTracerFactory, SpanName) - Constructor for class com.google.api.gax.tracing.TracedClientStreamingCallable
- TracedOperationCallable<RequestT,ResponseT,MetadataT> - Class in com.google.api.gax.tracing
-
This callable wraps a
OperationCallable
in aApiTracer
. - TracedOperationCallable(OperationCallable<RequestT, ResponseT, MetadataT>, ApiTracerFactory, SpanName) - Constructor for class com.google.api.gax.tracing.TracedOperationCallable
- TracedOperationInitialCallable<RequestT> - Class in com.google.api.gax.tracing
-
Traces the initial RPC of a long running operation.
- TracedOperationInitialCallable(UnaryCallable<RequestT, OperationSnapshot>, ApiTracerFactory, SpanName) - Constructor for class com.google.api.gax.tracing.TracedOperationInitialCallable
- TracedServerStreamingCallable<RequestT,ResponseT> - Class in com.google.api.gax.tracing
-
A wrapper callable that will wrap a callable chain in a trace.
- TracedServerStreamingCallable(ServerStreamingCallable<RequestT, ResponseT>, ApiTracerFactory, SpanName) - Constructor for class com.google.api.gax.tracing.TracedServerStreamingCallable
- TracedUnaryCallable<RequestT,ResponseT> - Class in com.google.api.gax.tracing
-
This callable wraps a callable chain in a
ApiTracer
. - TracedUnaryCallable(UnaryCallable<RequestT, ResponseT>, ApiTracerFactory, SpanName) - Constructor for class com.google.api.gax.tracing.TracedUnaryCallable
- TranslatingUnaryCallable<InnerRequestT,InnerResponseT,OuterRequestT,OuterResponseT> - Class in com.google.api.gax.rpc
-
A UnaryCallable that translates request types and response types using the given transformers.
- TransportChannel - Interface in com.google.api.gax.rpc
-
Class whose instances can issue RPCs on a particular transport.
- TransportChannelProvider - Interface in com.google.api.gax.rpc
-
Provides an interface to either build a TransportChannel or provide a fixed TransportChannel that will be used to make calls to a service.
U
- Unary - com.google.api.gax.tracing.ApiTracerFactory.OperationType
- UNARY - com.google.api.gax.httpjson.ApiMethodDescriptor.MethodType
- UnaryCallable<RequestT,ResponseT> - Class in com.google.api.gax.rpc
-
A UnaryCallable is an immutable object which is capable of making RPC calls to non-streaming API methods.
- UnaryCallable() - Constructor for class com.google.api.gax.rpc.UnaryCallable
- UnaryCallSettings<RequestT,ResponseT> - Class in com.google.api.gax.rpc
-
A base settings class to configure a UnaryCallable.
- UnaryCallSettings(UnaryCallSettings.Builder<RequestT, ResponseT>) - Constructor for class com.google.api.gax.rpc.UnaryCallSettings
- UnaryCallSettings.Builder<RequestT,ResponseT> - Class in com.google.api.gax.rpc
-
A base builder class for
UnaryCallSettings
. - unaryMethodSettingsBuilders() - Method in class com.google.api.gax.httpjson.longrunning.stub.OperationsStubSettings.Builder
- unaryMethodSettingsBuilders() - Method in class com.google.longrunning.stub.OperationsStubSettings.Builder
- UNAUTHENTICATED - com.google.api.gax.rpc.StatusCode.Code
- UnauthenticatedException - Exception in com.google.api.gax.rpc
-
Exception thrown when the request does not have valid authentication credentials for the operation.
- UnauthenticatedException(String, Throwable, StatusCode, boolean) - Constructor for exception com.google.api.gax.rpc.UnauthenticatedException
- UnauthenticatedException(Throwable, StatusCode, boolean) - Constructor for exception com.google.api.gax.rpc.UnauthenticatedException
- UnauthenticatedException(Throwable, StatusCode, boolean, ErrorDetails) - Constructor for exception com.google.api.gax.rpc.UnauthenticatedException
- UNAVAILABLE - com.google.api.gax.rpc.StatusCode.Code
- UnavailableException - Exception in com.google.api.gax.rpc
-
Exception thrown when the service is currently unavailable.
- UnavailableException(String, Throwable, StatusCode, boolean) - Constructor for exception com.google.api.gax.rpc.UnavailableException
- UnavailableException(Throwable, StatusCode, boolean) - Constructor for exception com.google.api.gax.rpc.UnavailableException
- UnavailableException(Throwable, StatusCode, boolean, ErrorDetails) - Constructor for exception com.google.api.gax.rpc.UnavailableException
- UNIMPLEMENTED - com.google.api.gax.rpc.StatusCode.Code
- UnimplementedException - Exception in com.google.api.gax.rpc
-
Exception thrown when the operation is not implemented or not supported/enabled in this service.
- UnimplementedException(String, Throwable, StatusCode, boolean) - Constructor for exception com.google.api.gax.rpc.UnimplementedException
- UnimplementedException(Throwable, StatusCode, boolean) - Constructor for exception com.google.api.gax.rpc.UnimplementedException
- UnimplementedException(Throwable, StatusCode, boolean, ErrorDetails) - Constructor for exception com.google.api.gax.rpc.UnimplementedException
- UNKNOWN - com.google.api.gax.httpjson.ApiMethodDescriptor.MethodType
- UNKNOWN - com.google.api.gax.rpc.StatusCode.Code
- UnknownException - Exception in com.google.api.gax.rpc
-
Exception thrown due to an unknown error.
- UnknownException(String, Throwable, StatusCode, boolean) - Constructor for exception com.google.api.gax.rpc.UnknownException
- UnknownException(Throwable, StatusCode, boolean) - Constructor for exception com.google.api.gax.rpc.UnknownException
- UnknownException(Throwable, StatusCode, boolean, ErrorDetails) - Constructor for exception com.google.api.gax.rpc.UnknownException
- updateRawPath(String, String) - Method in class com.google.api.gax.httpjson.ProtoMessageRequestFormatter.Builder
- useMtlsClientCertificate() - Method in class com.google.api.gax.rpc.mtls.MtlsProvider
-
Returns if mutual TLS client certificate should be used.
V
- validateBatch(BatchT) - Method in interface com.google.api.gax.batching.ThresholdBatchReceiver
-
Validate that the batch can be received by this ThresholdBatchReceiver.
- validateBatch(T) - Method in class com.google.api.gax.batching.AccumulatingBatchReceiver
- valueOf(String) - Static method in enum com.google.api.gax.batching.FlowController.LimitExceededBehavior
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.google.api.gax.httpjson.ApiMethodDescriptor.MethodType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.google.api.gax.rpc.mtls.MtlsProvider.MtlsEndpointUsagePolicy
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.google.api.gax.rpc.StatusCode.Code
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.google.api.gax.tracing.ApiTracerFactory.OperationType
-
Returns the enum constant of this type with the specified name.
- values() - Static method in enum com.google.api.gax.batching.FlowController.LimitExceededBehavior
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.google.api.gax.httpjson.ApiMethodDescriptor.MethodType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.google.api.gax.rpc.mtls.MtlsProvider.MtlsEndpointUsagePolicy
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.google.api.gax.rpc.StatusCode.Code
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.google.api.gax.tracing.ApiTracerFactory.OperationType
-
Returns an array containing the constants of this enum type, in the order they are declared.
W
- waitOperation(WaitOperationRequest) - Method in class com.google.longrunning.OperationsClient
-
Waits until the specified long-running operation is done or reaches at most a specified timeout, returning the latest state.
- waitOperationCallable() - Method in class com.google.longrunning.OperationsClient
-
Waits until the specified long-running operation is done or reaches at most a specified timeout, returning the latest state.
- waitOperationCallable() - Method in class com.google.longrunning.stub.GrpcOperationsStub
- waitOperationCallable() - Method in class com.google.longrunning.stub.OperationsStub
- waitOperationSettings() - Method in class com.google.longrunning.OperationsSettings.Builder
-
Returns the builder for the settings used for calls to deleteOperation.
- waitOperationSettings() - Method in class com.google.longrunning.OperationsSettings
-
Returns the object with the settings used for calls to waitOperation.
- waitOperationSettings() - Method in class com.google.longrunning.stub.OperationsStubSettings.Builder
-
Returns the builder for the settings used for calls to waitOperation.
- waitOperationSettings() - Method in class com.google.longrunning.stub.OperationsStubSettings
-
Returns the object with the settings used for calls to waitOperation.
- watch(ResponseObserver<ResponseT>, Duration, Duration) - Method in class com.google.api.gax.rpc.Watchdog
-
Wraps the target observer with timing constraints.
- Watchdog - Class in com.google.api.gax.rpc
-
Prevents the streams from hanging indefinitely.
- WatchdogProvider - Interface in com.google.api.gax.rpc
- WatchdogTimeoutException - Exception in com.google.api.gax.rpc
-
The marker exception thrown when a timeout is exceeded.
- watched(ServerStreamingCallable<RequestT, ResponseT>, ServerStreamingCallSettings<RequestT, ResponseT>, ClientContext) - Static method in class com.google.api.gax.rpc.Callables
- withCallOptions(HttpJsonCallOptions) - Method in class com.google.api.gax.httpjson.HttpJsonCallContext
- withCallOptions(CallOptions) - Method in class com.google.api.gax.grpc.GrpcCallContext
-
Returns a new instance with the call options set to the given call options.
- withChannel(HttpJsonChannel) - Method in class com.google.api.gax.httpjson.HttpJsonCallContext
- withChannel(Channel) - Method in class com.google.api.gax.grpc.GrpcCallContext
-
Returns a new instance with the channel set to the given channel.
- withChannelAffinity(Integer) - Method in class com.google.api.gax.grpc.GrpcCallContext
- withCheckInterval(Duration) - Method in class com.google.api.gax.rpc.FixedWatchdogProvider
- withCheckInterval(Duration) - Method in class com.google.api.gax.rpc.InstantiatingWatchdogProvider
- withCheckInterval(Duration) - Method in interface com.google.api.gax.rpc.WatchdogProvider
- withClock(ApiClock) - Method in class com.google.api.gax.rpc.FixedWatchdogProvider
- withClock(ApiClock) - Method in class com.google.api.gax.rpc.InstantiatingWatchdogProvider
- withClock(ApiClock) - Method in interface com.google.api.gax.rpc.WatchdogProvider
- withCredentials(Credentials) - Method in class com.google.api.gax.grpc.GrpcCallContext
- withCredentials(Credentials) - Method in class com.google.api.gax.grpc.InstantiatingGrpcChannelProvider
- withCredentials(Credentials) - Method in class com.google.api.gax.httpjson.HttpJsonCallContext
- withCredentials(Credentials) - Method in class com.google.api.gax.httpjson.InstantiatingHttpJsonChannelProvider
- withCredentials(Credentials) - Method in interface com.google.api.gax.rpc.ApiCallContext
-
Returns a new ApiCallContext with the given credentials set.
- withCredentials(Credentials) - Method in class com.google.api.gax.rpc.FixedTransportChannelProvider
- withCredentials(Credentials) - Method in interface com.google.api.gax.rpc.TransportChannelProvider
-
Sets the credentials that will be applied before channel creation.
- withDeadline(Instant) - Method in class com.google.api.gax.httpjson.HttpJsonCallContext
-
Deprecated.
- withDefaultCallContext(ApiCallContext) - Method in class com.google.api.gax.rpc.BidiStreamingCallable
-
Returns a new
BidiStreamingCallable
with anApiCallContext
that is used as a default when none is supplied in individual calls. - withDefaultCallContext(ApiCallContext) - Method in class com.google.api.gax.rpc.ClientStreamingCallable
-
Returns a new
ClientStreamingCallable
with anApiCallContext
that is used as a default when none is supplied in individual calls. - withDefaultCallContext(ApiCallContext) - Method in class com.google.api.gax.rpc.OperationCallable
-
Returns a new
OperationCallable
with anApiCallContext
that is used as a default when none is supplied in individual calls. - withDefaultCallContext(ApiCallContext) - Method in class com.google.api.gax.rpc.ServerStreamingCallable
-
Returns a new
ServerStreamingCallable
with anApiCallContext
that is used as a default when none is supplied in individual calls. - withDefaultCallContext(ApiCallContext) - Method in class com.google.api.gax.rpc.UnaryCallable
-
Returns a new
UnaryCallable
with anApiCallContext
that is used as a default when none is supplied in individual calls. - withEndpoint(String) - Method in class com.google.api.gax.grpc.InstantiatingGrpcChannelProvider
-
Specify the endpoint the channel should connect to.
- withEndpoint(String) - Method in class com.google.api.gax.httpjson.InstantiatingHttpJsonChannelProvider
- withEndpoint(String) - Method in class com.google.api.gax.rpc.FixedTransportChannelProvider
- withEndpoint(String) - Method in interface com.google.api.gax.rpc.TransportChannelProvider
-
Sets the endpoint to use when constructing a new
TransportChannel
. - withExecutor(Executor) - Method in class com.google.api.gax.grpc.InstantiatingGrpcChannelProvider
- withExecutor(Executor) - Method in class com.google.api.gax.httpjson.InstantiatingHttpJsonChannelProvider
- withExecutor(Executor) - Method in class com.google.api.gax.rpc.FixedTransportChannelProvider
- withExecutor(Executor) - Method in interface com.google.api.gax.rpc.TransportChannelProvider
-
Sets the executor to use when constructing a new
TransportChannel
. - withExecutor(ScheduledExecutorService) - Method in class com.google.api.gax.grpc.InstantiatingGrpcChannelProvider
-
Deprecated.
- withExecutor(ScheduledExecutorService) - Method in class com.google.api.gax.httpjson.InstantiatingHttpJsonChannelProvider
-
Deprecated.
- withExecutor(ScheduledExecutorService) - Method in class com.google.api.gax.rpc.FixedTransportChannelProvider
- withExecutor(ScheduledExecutorService) - Method in class com.google.api.gax.rpc.FixedWatchdogProvider
- withExecutor(ScheduledExecutorService) - Method in class com.google.api.gax.rpc.InstantiatingWatchdogProvider
- withExecutor(ScheduledExecutorService) - Method in interface com.google.api.gax.rpc.TransportChannelProvider
-
Deprecated.Please use
TransportChannelProvider.withExecutor(Executor)
. - withExecutor(ScheduledExecutorService) - Method in interface com.google.api.gax.rpc.WatchdogProvider
- withExtraHeaders(Map<String, List<String>>) - Method in class com.google.api.gax.grpc.GrpcCallContext
- withExtraHeaders(Map<String, List<String>>) - Method in class com.google.api.gax.httpjson.HttpJsonCallContext
- withExtraHeaders(Map<String, List<String>>) - Method in interface com.google.api.gax.rpc.ApiCallContext
-
Return a new ApiCallContext with the extraHeaders merged into the present instance.
- withHeaders(Map<String, String>) - Method in class com.google.api.gax.grpc.InstantiatingGrpcChannelProvider
- withHeaders(Map<String, String>) - Method in class com.google.api.gax.httpjson.InstantiatingHttpJsonChannelProvider
- withHeaders(Map<String, String>) - Method in class com.google.api.gax.rpc.FixedTransportChannelProvider
- withHeaders(Map<String, String>) - Method in interface com.google.api.gax.rpc.TransportChannelProvider
-
Sets the headers to use when constructing a new
TransportChannel
. - withOption(ApiCallContext.Key<T>, T) - Method in class com.google.api.gax.grpc.GrpcCallContext
-
Return a new ApiCallContext with additional option merged into the present instance.
- withOption(ApiCallContext.Key<T>, T) - Method in class com.google.api.gax.httpjson.HttpJsonCallContext
-
Return a new ApiCallContext with additional option merged into the present instance.
- withOption(ApiCallContext.Key<T>, T) - Method in interface com.google.api.gax.rpc.ApiCallContext
-
Return a new ApiCallContext with additional option merged into the present instance.
- withOption(ApiCallContext.Key<T>, T) - Method in class com.google.api.gax.rpc.internal.ApiCallContextOptions
-
Add an option.
- withPoolSize(int) - Method in class com.google.api.gax.grpc.InstantiatingGrpcChannelProvider
-
Deprecated.Please modify pool settings via
InstantiatingGrpcChannelProvider.toBuilder()
- withPoolSize(int) - Method in class com.google.api.gax.httpjson.InstantiatingHttpJsonChannelProvider
-
Deprecated.REST transport channel doesn't support channel pooling
- withPoolSize(int) - Method in class com.google.api.gax.rpc.FixedTransportChannelProvider
-
Deprecated.FixedTransportChannelProvider doesn't support ChannelPool configuration
- withPoolSize(int) - Method in interface com.google.api.gax.rpc.TransportChannelProvider
-
Deprecated.Pool settings should be configured on the builder of the specific implementation.
- withRequest(RequestT) - Method in class com.google.api.gax.rpc.PageContext
- withRequestParamsDynamicHeaderOption(String) - Method in class com.google.api.gax.grpc.GrpcCallContext
- withRetryableCodes(Set<StatusCode.Code>) - Method in class com.google.api.gax.grpc.GrpcCallContext
- withRetryableCodes(Set<StatusCode.Code>) - Method in class com.google.api.gax.httpjson.HttpJsonCallContext
- withRetryableCodes(Set<StatusCode.Code>) - Method in interface com.google.api.gax.rpc.ApiCallContext
-
Returns a new ApiCallContext with the given retryable codes set.
- withRetrySettings(RetrySettings) - Method in class com.google.api.gax.grpc.GrpcCallContext
- withRetrySettings(RetrySettings) - Method in class com.google.api.gax.httpjson.HttpJsonCallContext
- withRetrySettings(RetrySettings) - Method in interface com.google.api.gax.rpc.ApiCallContext
-
Returns a new ApiCallContext with the given
RetrySettings
set. - withStreamIdleTimeout(Duration) - Method in class com.google.api.gax.grpc.GrpcCallContext
- withStreamIdleTimeout(Duration) - Method in class com.google.api.gax.httpjson.HttpJsonCallContext
- withStreamIdleTimeout(Duration) - Method in interface com.google.api.gax.rpc.ApiCallContext
-
Returns a new ApiCallContext with the given stream idle timeout set.
- withStreamWaitTimeout(Duration) - Method in class com.google.api.gax.grpc.GrpcCallContext
- withStreamWaitTimeout(Duration) - Method in class com.google.api.gax.httpjson.HttpJsonCallContext
- withStreamWaitTimeout(Duration) - Method in interface com.google.api.gax.rpc.ApiCallContext
-
Returns a new ApiCallContext with the given stream timeout set.
- withTimeout(Duration) - Method in class com.google.api.gax.grpc.GrpcCallContext
- withTimeout(Duration) - Method in class com.google.api.gax.httpjson.HttpJsonCallContext
- withTimeout(Duration) - Method in interface com.google.api.gax.rpc.ApiCallContext
-
Returns a new ApiCallContext with the given timeout set.
- withTracer(ApiTracer) - Method in class com.google.api.gax.grpc.GrpcCallContext
-
Returns a new
ApiCallContext
with the givenApiTracer
. - withTracer(ApiTracer) - Method in class com.google.api.gax.httpjson.HttpJsonCallContext
-
Returns a new
ApiCallContext
with the givenApiTracer
. - withTracer(ApiTracer) - Method in interface com.google.api.gax.rpc.ApiCallContext
-
Returns a new
ApiCallContext
with the givenApiTracer
. - withTransportChannel(TransportChannel) - Method in class com.google.api.gax.grpc.GrpcCallContext
- withTransportChannel(TransportChannel) - Method in class com.google.api.gax.httpjson.HttpJsonCallContext
- withTransportChannel(TransportChannel) - Method in interface com.google.api.gax.rpc.ApiCallContext
-
Returns a new ApiCallContext with the given channel set.
All Classes All Packages