- 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(Throwable, StatusCode, boolean) - Constructor for exception com.google.api.gax.rpc.AbortedException
-
- AbortedException(String, Throwable, StatusCode, boolean) - 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
-
- 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
-
- 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
-
- AbstractPagedListResponse(PageT, CollectionT) - Constructor for class com.google.api.gax.paging.AbstractPagedListResponse
-
- acceptsPoolSize() - Method in class com.google.api.gax.grpc.InstantiatingGrpcChannelProvider
-
- acceptsPoolSize() - Method in class com.google.api.gax.httpjson.InstantiatingHttpJsonChannelProvider
-
- acceptsPoolSize() - Method in class com.google.api.gax.rpc.FixedTransportChannelProvider
-
- acceptsPoolSize() - Method in interface com.google.api.gax.rpc.TransportChannelProvider
-
Reports whether this provider allows pool size customization.
- 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(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(E) - Method in class com.google.api.gax.batching.ThresholdBatcher
-
Adds an element to the batcher.
- 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.
- 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(Throwable, StatusCode, boolean) - Constructor for exception com.google.api.gax.rpc.AlreadyExistsException
-
- AlreadyExistsException(String, Throwable, StatusCode, boolean) - Constructor for exception com.google.api.gax.rpc.AlreadyExistsException
-
- ApiCallContext - Interface in com.google.api.gax.rpc
-
Context for an API call.
- 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(Throwable, StatusCode, boolean) - Constructor for exception com.google.api.gax.rpc.ApiException
-
- ApiException(String, Throwable, StatusCode, boolean) - 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
-
- ApiMessage - Interface in com.google.api.gax.httpjson
-
- ApiMessageHttpRequestFormatter<RequestT extends ApiMessage> - Class in com.google.api.gax.httpjson
-
Utility class to parse ApiMessages into various HTTP request parts.
- ApiMessageHttpRequestFormatter() - Constructor for class com.google.api.gax.httpjson.ApiMessageHttpRequestFormatter
-
- ApiMessageHttpRequestFormatter.Builder<RequestT extends ApiMessage> - Class in com.google.api.gax.httpjson
-
- ApiMessageHttpResponseParser<ResponseT extends ApiMessage> - Class in com.google.api.gax.httpjson
-
Utility class to parse
ApiMessage
s from HTTP responses.
- ApiMessageHttpResponseParser() - Constructor for class com.google.api.gax.httpjson.ApiMessageHttpResponseParser
-
- ApiMessageHttpResponseParser.Builder<ResponseT extends ApiMessage> - Class in com.google.api.gax.httpjson
-
- ApiMessageOperationTransformers - Class in com.google.api.gax.httpjson
-
Transformers from OperationSnapshot wrappers to the underlying native ApiMessage objects.
- ApiMessageOperationTransformers.MetadataTransformer<MetadataT extends ApiMessage> - Class in com.google.api.gax.httpjson
-
- ApiMessageOperationTransformers.ResponseTransformer<ResponseT extends ApiMessage> - Class in com.google.api.gax.httpjson
-
- 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
-
- 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
-
- 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.ApiMessageOperationTransformers.MetadataTransformer
-
Unwraps an OperationSnapshot and returns the contained operation metadata message.
- apply(OperationSnapshot) - Method in class com.google.api.gax.httpjson.ApiMessageOperationTransformers.ResponseTransformer
-
Unwraps an OperationSnapshot and returns the contained method response message.
- 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.
- 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.
- 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.NoopApiTracer
-
- 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.NoopApiTracer
-
- 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.NoopApiTracer
-
- 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.NoopApiTracer
-
- 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
-
Adds an annotation that an attempt is about to start.
- attemptStarted(int) - Method in class com.google.api.gax.tracing.NoopApiTracer
-
- attemptStarted(int) - Method in class com.google.api.gax.tracing.OpencensusTracer
-
Adds an annotation that an attempt is about to start.
- 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.NoopApiTracer
-
- attemptSucceeded() - Method in class com.google.api.gax.tracing.OpencensusTracer
-
Adds an annotation that the attempt succeeded.
- 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.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
-
- 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() - 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(RequestT, ApiCallContext) - Method in class com.google.api.gax.rpc.OperationCallable
-
Perform a call synchronously.
- call(RequestT) - Method in class com.google.api.gax.rpc.OperationCallable
-
- call(RequestT) - Method in class com.google.api.gax.rpc.ServerStreamingCallable
-
Conduct a iteration server streaming call.
- call(RequestT, ApiCallContext) - Method in class com.google.api.gax.rpc.ServerStreamingCallable
-
- call(RequestT, ResponseObserver<ResponseT>, ApiCallContext) - Method in class com.google.api.gax.rpc.ServerStreamingCallable
-
- call(RequestT, ResponseObserver<ResponseT>) - Method in class com.google.api.gax.rpc.ServerStreamingCallable
-
Conduct a server streaming call
- call(RequestT, ApiCallContext) - Method in class com.google.api.gax.rpc.UnaryCallable
-
Perform a call synchronously.
- call(RequestT) - Method in class com.google.api.gax.rpc.UnaryCallable
-
- 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 be UncheckedExecutionException
), the exception is processed in the following way:
If the exception cause is a RuntimeException, the RuntimeException is rethrown.
- cancel(boolean) - Method in class com.google.api.gax.longrunning.OperationFutureImpl
-
- cancel(boolean) - Method in class com.google.api.gax.retrying.NonCancellableFuture
-
- 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) - Method in class com.google.api.gax.rpc.OperationCallable
-
Sends a cancellation request to the server for the operation with name operationName
.
- 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(String, ApiCallContext) - Method in class com.google.api.gax.tracing.TracedOperationCallable
-
- CancelledException - Exception in com.google.api.gax.rpc
-
The exception thrown when the operation was cancelled (typically by the caller).
- CancelledException(Throwable, StatusCode, boolean) - Constructor for exception com.google.api.gax.rpc.CancelledException
-
- CancelledException(String, Throwable, StatusCode, boolean) - Constructor for exception com.google.api.gax.rpc.CancelledException
-
- cancelOperation(String) - Method in class com.google.longrunning.OperationsClient
-
Starts asynchronous cancellation on a long-running operation.
- 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.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
-
- 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
- ChannelPrimer - Interface in com.google.api.gax.grpc
-
An interface to prepare a ManagedChannel for normal requests by priming the channel
- 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.
- clientStreamingCall(ApiStreamObserver<ResponseT>, ApiCallContext) - Method in class com.google.api.gax.rpc.ClientStreamingCallable
-
- 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.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.
- clone() - Method in class com.google.api.gax.httpjson.EmptyMessage.Builder
-
- close() - Method in interface com.google.api.gax.batching.Batcher
-
Closes this Batcher by preventing new elements from being added and 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 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.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
-
- 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.longrunning - package com.google.api.gax.longrunning
-
- 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.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.NoopApiTracer
-
- connectionSelected(String) - Method in class com.google.api.gax.tracing.OpencensusTracer
-
Annotates the operation with selected connection id from the ChannelPool
.
- 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(ElementT, SettableApiFuture<ElementResultT>) - Static method in class com.google.api.gax.batching.BatchEntry
-
Returns a new BatchEntry
- 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(Credentials) - Static method in class com.google.api.gax.core.FixedCredentialsProvider
-
Creates a FixedCredentialsProvider.
- create(ScheduledExecutorService) - Static method in class com.google.api.gax.core.FixedExecutorProvider
-
Creates a FixedExecutorProvider.
- create() - Static method in class com.google.api.gax.core.NoCredentialsProvider
-
- create(MethodDescriptor<RequestT, ResponseT>) - Static method in class com.google.api.gax.grpc.GrpcCallSettings
-
- create(ManagedChannel) - Static method in class com.google.api.gax.grpc.GrpcTransportChannel
-
- 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<MetadataT>) - Static method in class com.google.api.gax.httpjson.ApiMessageOperationTransformers.MetadataTransformer
-
- create(Class<ResponseT>) - Static method in class com.google.api.gax.httpjson.ApiMessageOperationTransformers.ResponseTransformer
-
- create(ApiMethodDescriptor<RequestT, ResponseT>) - Static method in class com.google.api.gax.httpjson.HttpJsonCallSettings
-
- create(String, String) - Static method in class com.google.api.gax.httpjson.HttpJsonHeaderEnhancers
-
- create() - Static method in class com.google.api.gax.httpjson.ProtoRestSerializer
-
Creates a new instance of ProtoRestSerializer.
- 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() - Static method in class com.google.api.gax.rpc.BatchedFuture
-
Get a new instance.
- 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(Map<String, String>) - Static method in class com.google.api.gax.rpc.FixedHeaderProvider
-
Creates a FixedHeaderProvider.
- create(String...) - Static method in class com.google.api.gax.rpc.FixedHeaderProvider
-
- create(TransportChannel) - Static method in class com.google.api.gax.rpc.FixedTransportChannelProvider
-
Creates a FixedTransportChannelProvider.
- create(Watchdog) - Static method in class com.google.api.gax.rpc.FixedWatchdogProvider
-
- create() - Static method in class com.google.api.gax.rpc.InstantiatingWatchdogProvider
-
- create(UnaryCallable<RequestT, ResponseT>, PagedListDescriptor<RequestT, ResponseT, ResourceT>, RequestT, ApiCallContext) - Static method in class com.google.api.gax.rpc.PageContext
-
- create(UnaryCallable<InnerRequestT, InnerResponseT>, ApiFunction<OuterRequestT, InnerRequestT>, ApiFunction<InnerResponseT, OuterResponseT>) - Static method in class com.google.api.gax.rpc.TranslatingUnaryCallable
-
- 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(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(ClientContext) - Static method in class com.google.longrunning.stub.GrpcOperationsStub
-
- create(ClientContext, GrpcStubCallableFactory) - Static method in class com.google.longrunning.stub.GrpcOperationsStub
-
- 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(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(GrpcCallSettings<RequestT, ResponseT>, BatchingCallSettings<RequestT, ResponseT>, ClientContext) - Method in class com.google.longrunning.stub.GrpcOperationsCallableFactory
-
- 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>, Set<StatusCode.Code>) - Static method in class com.google.api.gax.grpc.GrpcRawCallableFactory
-
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
-
- 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>, Set<StatusCode.Code>) - Static method in class com.google.api.gax.grpc.GrpcRawCallableFactory
-
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
-
- createCollection(List<PageT>, int) - Method in class com.google.api.gax.paging.AbstractFixedSizeCollection
-
- createCollection(List<OperationsClient.ListOperationsPage>, int) - Method in class com.google.longrunning.OperationsClient.ListOperationsFixedSizeCollection
-
- 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(Throwable, StatusCode, boolean) - Static method in class com.google.api.gax.rpc.ApiExceptionFactory
-
- createException(String, Throwable, StatusCode, boolean) - Static method in class com.google.api.gax.rpc.ApiExceptionFactory
-
- createFirstAttempt() - Method in class com.google.api.gax.retrying.ExponentialRetryAlgorithm
-
- createFirstAttempt(RetryingContext) - Method in class com.google.api.gax.retrying.ExponentialRetryAlgorithm
-
- createFirstAttempt() - Method in class com.google.api.gax.retrying.RetryAlgorithm
-
- createFirstAttempt(RetryingContext) - Method in class com.google.api.gax.retrying.RetryAlgorithm
-
- createFirstAttempt() - Method in interface com.google.api.gax.retrying.TimedRetryAlgorithm
-
- createFirstAttempt(RetryingContext) - Method in interface com.google.api.gax.retrying.TimedRetryAlgorithmWithContext
-
- 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>, 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>) - 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>, RetryingContext) - Method in interface com.google.api.gax.retrying.RetryingExecutorWithContext
-
- 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.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(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(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(TimedAttemptSettings) - Method in class com.google.api.gax.retrying.ExponentialRetryAlgorithm
-
- createNextAttempt(RetryingContext, TimedAttemptSettings) - Method in class com.google.api.gax.retrying.ExponentialRetryAlgorithm
-
- createNextAttempt(Throwable, ResponseT, TimedAttemptSettings) - Method in interface com.google.api.gax.retrying.ResultRetryAlgorithm
-
- createNextAttempt(RetryingContext, Throwable, ResponseT, TimedAttemptSettings) - Method in interface com.google.api.gax.retrying.ResultRetryAlgorithmWithContext
-
- createNextAttempt(Throwable, ResponseT, TimedAttemptSettings) - Method in class com.google.api.gax.retrying.RetryAlgorithm
-
- createNextAttempt(RetryingContext, Throwable, ResponseT, TimedAttemptSettings) - Method in class com.google.api.gax.retrying.RetryAlgorithm
-
- createNextAttempt(Throwable, ResponseT, TimedAttemptSettings) - Method in class com.google.api.gax.retrying.StreamingRetryAlgorithm
-
- createNextAttempt(RetryingContext, Throwable, ResponseT, TimedAttemptSettings) - Method in class com.google.api.gax.retrying.StreamingRetryAlgorithm
-
- createNextAttempt(TimedAttemptSettings) - Method in interface com.google.api.gax.retrying.TimedRetryAlgorithm
-
- createNextAttempt(RetryingContext, TimedAttemptSettings) - Method in interface com.google.api.gax.retrying.TimedRetryAlgorithmWithContext
-
- 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(OperationCallSettings<RequestT, ResponseT, MetadataT>, ClientContext, LongRunningClient, UnaryCallable<RequestT, OperationSnapshot>) - Static method in class com.google.api.gax.httpjson.HttpJsonCallableFactory
-
- createOperationCallable(HttpJsonCallSettings<RequestT, OperationT>, OperationCallSettings<RequestT, ResponseT, MetadataT>, ClientContext, OperationsStub) - Method in interface com.google.api.gax.httpjson.HttpJsonStubCallableFactory
-
- createOperationCallable(GrpcCallSettings<RequestT, Operation>, OperationCallSettings<RequestT, ResponseT, MetadataT>, ClientContext, OperationsStub) - Method in class com.google.longrunning.stub.GrpcOperationsCallableFactory
-
- createPage(PageContext<RequestT, ResponseT, ResourceT>, ResponseT) - Method in class com.google.api.gax.paging.AbstractPage
-
- createPage(PageContext<ListOperationsRequest, ListOperationsResponse, Operation>, 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
-
- createPageAsync(PageContext<ListOperationsRequest, ListOperationsResponse, Operation>, ApiFuture<ListOperationsResponse>) - Method in class com.google.longrunning.OperationsClient.ListOperationsPage
-
- 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(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(GrpcCallSettings<RequestT, ResponseT>, PagedCallSettings<RequestT, ResponseT, PagedListResponseT>, 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
-
- 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>, Set<StatusCode.Code>) - Static method in class com.google.api.gax.grpc.GrpcRawCallableFactory
-
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
-
- createSingleChannel() - Method in interface com.google.api.gax.grpc.ChannelFactory
-
- 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>, Set<StatusCode.Code>) - Static method in class com.google.api.gax.grpc.GrpcRawCallableFactory
-
Create a Unary callable object with minimal 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(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(GrpcCallSettings<RequestT, ResponseT>, UnaryCallSettings<RequestT, ResponseT>, ClientContext) - Method in class com.google.longrunning.stub.GrpcOperationsCallableFactory
-
- 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.
- 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
-
- getApiClientHeaderKey() - Method in class com.google.api.gax.rpc.ApiClientHeaderProvider.Builder
-
- getApiMessageRequestBody() - Method in interface com.google.api.gax.httpjson.ApiMessage
-
- getApiMessageRequestBody() - Method in class com.google.api.gax.httpjson.EmptyMessage
-
- 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
-
- 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.
- 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
-
- 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.
- 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.
- 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
-
- 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
-
- getDeadline() - Method in class com.google.api.gax.httpjson.HttpJsonCallOptions
-
- 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
-
- getDefaultInstance() - Static method in class com.google.api.gax.batching.FlowControlSettings
-
- getDefaultInstance() - Static method in class com.google.api.gax.httpjson.EmptyMessage
-
- getDefaultResourceHeaderKey() - Static method in class com.google.api.gax.rpc.ApiClientHeaderProvider
-
- getDelayThreshold() - Method in class com.google.api.gax.batching.BatchingSettings
-
Get the delay threshold to use for batching.
- 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 this
TransportChannel
.
- 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
-
- 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.
- 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
-
- 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
-
- getExecutorProvider() - Method in class com.google.api.gax.rpc.ClientSettings.Builder
-
Gets the ExecutorProvider that was previously set on this Builder.
- getExecutorProvider() - Method in class com.google.api.gax.rpc.ClientSettings
-
- getExecutorProvider() - Method in class com.google.api.gax.rpc.StubSettings.Builder
-
Gets the ExecutorProvider that was previously set on this Builder.
- getExecutorProvider() - Method in class com.google.api.gax.rpc.StubSettings
-
- 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.
- getFieldMask() - Method in interface com.google.api.gax.httpjson.ApiMessage
-
- getFieldMask() - Method in class com.google.api.gax.httpjson.EmptyMessage
-
- getFieldValue(String) - Method in interface com.google.api.gax.httpjson.ApiMessage
-
- getFieldValue(String) - Method in class com.google.api.gax.httpjson.EmptyMessage
-
- 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.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
-
- 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
-
- 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
-
- getInitialFuture() - Method in interface com.google.api.gax.longrunning.OperationFuture
-
Returns the
OperationSnapshot
future of the initial request which started this
OperationFuture
.
- 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.NoopApiTracer
-
- getInstance() - Static method in class com.google.api.gax.tracing.NoopApiTracerFactory
-
- getInterceptors() - Method in interface com.google.api.gax.grpc.GrpcInterceptorProvider
-
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.
- 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.
- 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.
- 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.
- 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 interface com.google.api.gax.longrunning.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.
- 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
-
- getMethodName() - Method in class com.google.api.gax.tracing.SpanName
-
The name of the logical operation being traced.
- 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
-
- 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(int) - 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.
- 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(String) - Method in class com.google.longrunning.OperationsClient
-
Gets the latest state of a long-running operation.
- 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.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.
- 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(RequestT) - Method in class com.google.api.gax.httpjson.ApiMessageHttpRequestFormatter
-
- 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 class com.google.api.gax.httpjson.ApiMessageHttpRequestFormatter
-
Path template for endpoint URL path.
- 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
-
- getPollingFuture() - Method in class com.google.api.gax.longrunning.OperationFutureImpl
-
- getPoolSize() - Method in class com.google.api.gax.grpc.InstantiatingGrpcChannelProvider.Builder
-
Number of underlying grpc channels to open.
- 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() - Method in class com.google.api.gax.httpjson.ApiMessageHttpRequestFormatter
-
- getQueryParamNames(RequestT) - Method in class com.google.api.gax.httpjson.ApiMessageHttpRequestFormatter
-
- 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
-
- 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.
- 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(ApiMessage) - Method in class com.google.api.gax.httpjson.ApiMessageHttpRequestFormatter
-
- 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
-
- getRequestIssuerList() - Method in class com.google.api.gax.rpc.Batch
-
- getRequestMetadata(URI) - Method in class com.google.api.gax.rpc.internal.QuotaProjectIdHidingCredentials
-
- getRequestMetadata() - Method in class com.google.api.gax.rpc.internal.QuotaProjectIdHidingCredentials
-
- getResourceHeaderKey() - Method in class com.google.api.gax.rpc.ApiClientHeaderProvider.Builder
-
- getResourceNameFactory() - Method in class com.google.api.gax.httpjson.ApiMessageHttpRequestFormatter
-
A ResourceNameFactory that can parse the resource name String into a ResourceName object.
- getResourceNameField() - Method in class com.google.api.gax.httpjson.ApiMessageHttpRequestFormatter
-
The name of the field in the RequestT that contains the resource name path.
- getResourceToken() - Method in class com.google.api.gax.rpc.ApiClientHeaderProvider.Builder
-
- 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
-
- getResponseInstance() - Method in class com.google.api.gax.httpjson.ApiMessageHttpResponseParser
-
- getResponseMarshaller() - Method in class com.google.api.gax.httpjson.ApiMessageHttpResponseParser
-
- 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
-
- 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
-
- 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.
- 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
-
- getRetrySettings() - Method in class com.google.api.gax.rpc.ServerStreamingCallSettings.Builder
-
- getRetrySettings() - Method in class com.google.api.gax.rpc.ServerStreamingCallSettings
-
- 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.longrunning.OperationsClient
-
- getStatusCode() - Method in exception com.google.api.gax.rpc.ApiException
-
Returns the status code of the underlying exception.
- 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
-
- 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
-
- 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
-
- getStreamWatchdogProvider() - Method in class com.google.api.gax.rpc.StubSettings
-
- 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.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
-
- 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
-
- 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
-
- 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 and retryAlgorithm
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.
- 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(ResponseT) - Method in class com.google.api.gax.httpjson.ApiMessageHttpResponseParser
-
- serialize(ApiMessage, Type, JsonSerializationContext) - Method in class com.google.api.gax.httpjson.FieldMaskedSerializer
-
- 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
-
- ServerStream<V> - Class in com.google.api.gax.rpc
-
A blocking Iterable-style wrapper around server stream responses.
- ServerStreamingAttemptException - Exception in com.google.api.gax.retrying
-
A wrapper exception thrown by
ServerStreamingAttemptCallable
to communicate additional
context to the
StreamingRetryAlgorithm
and to pass the original cancellation stack trace
to
RetryingServerStreamingCallable
.
- ServerStreamingAttemptException(Throwable, boolean, boolean) - Constructor for exception com.google.api.gax.retrying.ServerStreamingAttemptException
-
- serverStreamingCall(RequestT, ApiStreamObserver<ResponseT>, ApiCallContext) - Method in class com.google.api.gax.rpc.ServerStreamingCallable
-
- serverStreamingCall(RequestT, ApiStreamObserver<ResponseT>) - Method in class com.google.api.gax.rpc.ServerStreamingCallable
-
- 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
-
- ServerStreamingCallSettings.Builder<RequestT,ResponseT> - Class in com.google.api.gax.rpc
-
- set(ResponseT) - Method in class com.google.api.gax.rpc.BatchedFuture
-
- 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.
- 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.
- 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
-
Sets the number of channels relative to the available CPUs.
- setChannelsPerCpu(double, int) - Method in class com.google.api.gax.grpc.InstantiatingGrpcChannelProvider.Builder
-
- 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
-
- 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.
- 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
-
- 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(ScheduledExecutorService) - Method in class com.google.api.gax.batching.ThresholdBatcher.Builder
-
Set the executor for the ThresholdBatcher.
- 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.rpc.ClientContext.Builder
-
- setExecutorProvider(ExecutorProvider) - Method in class com.google.api.gax.grpc.InstantiatingGrpcChannelProvider.Builder
-
- setExecutorProvider(ExecutorProvider) - Method in class com.google.api.gax.httpjson.InstantiatingHttpJsonChannelProvider.Builder
-
- setExecutorProvider(ExecutorProvider) - Method in class com.google.api.gax.rpc.ClientSettings.Builder
-
Sets the ExecutorProvider to use for getting the executor to use for running asynchronous API
call logic (such as retries and long-running operations), and also to pass to the transport
settings if an executor is needed for the transport and it doesn't have its own executor
provider.
- setExecutorProvider(ExecutorProvider) - Method in class com.google.api.gax.rpc.StubSettings.Builder
-
Sets the ExecutorProvider to use for getting the executor to use for running asynchronous API
call logic (such as retries and long-running operations), and also to pass to the transport
settings if an executor is needed for the transport and it doesn't have its own executor
provider.
- 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
-
- setHeaderEnhancers(List<HttpJsonHeaderEnhancer>) - Method in class com.google.api.gax.httpjson.ManagedHttpJsonChannel.Builder
-
- 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
-
- 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.
- 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.
- 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
-
- 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(ManagedChannel) - Method in class com.google.api.gax.grpc.GrpcTransportChannel.Builder
-
- setManagedChannel(ManagedHttpJsonChannel) - Method in class com.google.api.gax.httpjson.HttpJsonTransportChannel.Builder
-
- setMaxAttempts(int) - Method in class com.google.api.gax.retrying.RetrySettings.Builder
-
MaxAttempts defines the maximum number of attempts to perform.
- 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.
- 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.
- setMetadataTransformer(ApiFunction<OperationSnapshot, MetadataT>) - Method in class com.google.api.gax.rpc.OperationCallSettings.Builder
-
- setMethodDescriptor(MethodDescriptor<RequestT, ResponseT>) - Method in class com.google.api.gax.grpc.GrpcCallSettings.Builder
-
- setMethodDescriptor(ApiMethodDescriptor<RequestT, ResponseT>) - Method in class com.google.api.gax.httpjson.HttpJsonCallSettings.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
-
- 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
-
- setPathTemplate(PathTemplate) - Method in class com.google.api.gax.httpjson.ApiMessageHttpRequestFormatter.Builder
-
- setPollingAlgorithm(TimedRetryAlgorithm) - Method in class com.google.api.gax.rpc.OperationCallSettings.Builder
-
Set the polling algorithm of the operation.
- setPoolSize(int) - Method in class com.google.api.gax.grpc.InstantiatingGrpcChannelProvider.Builder
-
Number of underlying grpc channels to open.
- setQueryParams(Set<String>) - Method in class com.google.api.gax.httpjson.ApiMessageHttpRequestFormatter.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.
- 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
-
- setResourceNameFactory(ResourceNameFactory) - Method in class com.google.api.gax.httpjson.ApiMessageHttpRequestFormatter.Builder
-
- setResourceNameField(String) - Method in class com.google.api.gax.httpjson.ApiMessageHttpRequestFormatter.Builder
-
- setResourceToken(String) - Method in class com.google.api.gax.rpc.ApiClientHeaderProvider.Builder
-
- setResponse(ResponseT) - Method in class com.google.api.gax.rpc.BatchedRequestIssuer
-
Set the response to set on the batched future.
- setResponseInstance(ResponseT) - Method in class com.google.api.gax.httpjson.ApiMessageHttpResponseParser.Builder
-
- 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
-
- 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(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(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(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
-
- setRetryableCodes(Set<StatusCode.Code>) - Method in class com.google.api.gax.rpc.ServerStreamingCallSettings.Builder
-
- 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.
- 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.
- 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
-
- 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
-
- setRetrySettings(RetrySettings) - Method in class com.google.api.gax.rpc.UnaryCallSettings.Builder
-
- 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.
- 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
-
- 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
-
- setTracerFactory(ApiTracerFactory) - Method in class com.google.api.gax.rpc.StubSettings.Builder
-
- 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
-
- 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
-
- shouldRetry(Throwable, OperationSnapshot) - Method in class com.google.api.gax.longrunning.OperationResponsePollAlgorithm
-
- shouldRetry(TimedAttemptSettings) - Method in class com.google.api.gax.longrunning.OperationTimedPollAlgorithm
-
Returns true
if another poll operation should be made or throws CancellationException
otherwise.
- shouldRetry(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 class com.google.api.gax.retrying.BasicResultRetryAlgorithm
-
Returns true
if an exception was thrown (previousThrowable != null
), false
otherwise.
- shouldRetry(TimedAttemptSettings) - Method in class com.google.api.gax.retrying.ExponentialPollAlgorithm
-
Returns
true
if another poll operation should be made or throws
PollException
,
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, or false
otherwise.
- shouldRetry(RetryingContext, TimedAttemptSettings) - Method in class com.google.api.gax.retrying.ExponentialRetryAlgorithm
-
Returns true
if another attempt should be made, or false
otherwise.
- shouldRetry(Throwable, ResponseT) - Method in interface com.google.api.gax.retrying.ResultRetryAlgorithm
-
- shouldRetry(RetryingContext, Throwable, ResponseT) - Method in interface com.google.api.gax.retrying.ResultRetryAlgorithmWithContext
-
Returns true
if another attempt should be made, or false
otherwise.
- shouldRetry(Throwable, ResponseT, TimedAttemptSettings) - Method in class com.google.api.gax.retrying.RetryAlgorithm
-
- shouldRetry(RetryingContext, Throwable, ResponseT, TimedAttemptSettings) - Method in class com.google.api.gax.retrying.RetryAlgorithm
-
Returns true
if another attempt should be made, or false
otherwise.
- shouldRetry(Throwable, ResponseT, TimedAttemptSettings) - Method in class com.google.api.gax.retrying.StreamingRetryAlgorithm
-
Returns true
if another attempt should be made, or false
otherwise.
- shouldRetry(RetryingContext, Throwable, ResponseT, TimedAttemptSettings) - Method in class com.google.api.gax.retrying.StreamingRetryAlgorithm
-
Returns true
if another attempt should be made, or false
otherwise.
- shouldRetry(TimedAttemptSettings) - Method in interface com.google.api.gax.retrying.TimedRetryAlgorithm
-
- shouldRetry(RetryingContext, TimedAttemptSettings) - Method in interface com.google.api.gax.retrying.TimedRetryAlgorithmWithContext
-
Returns true
if another attempt should be made, or false
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.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.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
-
- SimpleStreamResumptionStrategy<RequestT,ResponseT> - Class in com.google.api.gax.retrying
-
- 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, List<BatchEntry<ElementT, ElementResultT>>) - Method in interface com.google.api.gax.batching.BatchingDescriptor
-
Unpacks the batch response error into individual element errors.
- 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.
- splitResponse(ResponseT, List<BatchEntry<ElementT, ElementResultT>>) - Method in interface com.google.api.gax.batching.BatchingDescriptor
-
Unpacks the batch response into individual elements results.
- 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.
- StateCheckingResponseObserver<V> - Class in com.google.api.gax.rpc
-
- StateCheckingResponseObserver() - Constructor for class com.google.api.gax.rpc.StateCheckingResponseObserver
-
- 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
-
- 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
-
- StreamingRetryAlgorithm(ResultRetryAlgorithmWithContext<ResponseT>, TimedRetryAlgorithmWithContext) - Constructor for class com.google.api.gax.retrying.StreamingRetryAlgorithm
-
- 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
-
- 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.