Skip navigation links
A B C D E F G H I J L M N O P R S T U V W 

A

AbstractRetryingOperation<RequestT,ResponseT,ResultT> - Class in com.google.cloud.bigtable.grpc.async
A ClientCall.Listener that retries a BigtableAsyncRpc request.
AbstractRetryingOperation(RetryOptions, RequestT, BigtableAsyncRpc<RequestT, ResponseT>, CallOptions, ScheduledExecutorService, Metadata, ApiClock) - Constructor for class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation
Constructor for AbstractRetryingRpcListener.
AbstractRetryingOperation.GrpcFuture<RespT> - Class in com.google.cloud.bigtable.grpc.async
 
adapt(ApiFuture<T>) - Static method in class com.google.cloud.bigtable.util.ApiFutureUtil
 
adapt(ListenableFuture<T>) - Static method in class com.google.cloud.bigtable.util.ApiFutureUtil
 
add(RowMutationEntry) - Method in interface com.google.cloud.bigtable.core.IBulkMutation
Adds a RowMutationEntry to the underlying IBulkMutation mechanism.
add(MutateRowRequest) - Method in class com.google.cloud.bigtable.grpc.async.BulkMutation
 
add(MutateRowsRequest.Entry) - Method in class com.google.cloud.bigtable.grpc.async.BulkMutation
Adds a MutateRowsRequest.Entry to the MutateRowsRequest.Builder.
add(RowMutationEntry) - Method in class com.google.cloud.bigtable.grpc.async.BulkMutationGCJClient
Adds a RowMutationEntry to the underlying IBulkMutation mechanism.
add(RowMutationEntry) - Method in class com.google.cloud.bigtable.grpc.async.BulkMutationWrapper
Adds a RowMutationEntry to the underlying IBulkMutation mechanism.
add(Query) - Method in class com.google.cloud.bigtable.grpc.async.BulkRead
Adds the key in the request to a batch read.
addCell(String, ByteString, long, ByteString, List<String>) - Method in class com.google.cloud.bigtable.grpc.scanner.FlatRow.Builder
 
addCell(String, ByteString, long, ByteString) - Method in class com.google.cloud.bigtable.grpc.scanner.FlatRow.Builder
 
addCell(FlatRow.Cell) - Method in class com.google.cloud.bigtable.grpc.scanner.FlatRow.Builder
 
addRequestResultMarker() - Method in class com.google.cloud.bigtable.grpc.scanner.ResponseQueueReader
This marker notifies ResponseQueueReader.getNextMergedRow() to request more results and allows for flow control based on the state of the ResponseQueueReader.resultQueue.
addStatusToRetryOn(Status.Code) - Method in class com.google.cloud.bigtable.config.RetryOptions.Builder
 
allowRetriesWithoutTimestamp() - Method in class com.google.cloud.bigtable.config.RetryOptions
Should retries be allowed even if a timestamp isn't set?
ApiFutureUtil - Class in com.google.cloud.bigtable.util
For internal use only - public for technical reasons.
ApiFutureUtil() - Constructor for class com.google.cloud.bigtable.util.ApiFutureUtil
 
authority() - Method in class com.google.cloud.bigtable.grpc.io.ChannelPool
available() - Method in class com.google.cloud.bigtable.grpc.scanner.ResponseQueueReader
available.
available() - Method in interface com.google.cloud.bigtable.grpc.scanner.ResultScanner
Check number of rows immediately available.
available() - Method in class com.google.cloud.bigtable.grpc.scanner.ResumingStreamingResultScanner
Check number of rows immediately available.
available() - Method in class com.google.cloud.bigtable.grpc.scanner.RowResultScanner
 
awaitCompletion() - Method in class com.google.cloud.bigtable.grpc.async.OperationAccountant
Blocks until all outstanding RPCs and retries have completed
awaitTermination(long, TimeUnit) - Method in class com.google.cloud.bigtable.grpc.io.ChannelPool

B

batchThreadPool - Variable in class com.google.cloud.bigtable.grpc.BigtableSessionSharedThreadPools
This is used to do i/o work.
beforeStart(ClientCallStreamObserver<ReadRowsRequest>) - Method in class com.google.cloud.bigtable.grpc.scanner.ResponseQueueReader
 
BIGTABLE_ADMIN_HOST_DEFAULT - Static variable in class com.google.cloud.bigtable.config.BigtableOptions
For internal use only - public for technical reasons.
BIGTABLE_APP_PROFILE_DEFAULT - Static variable in class com.google.cloud.bigtable.config.BigtableOptions
Constant BIGTABLE_APP_PROFILE_DEFAULT="", defaults to the server default app profile
BIGTABLE_ASYNC_MUTATOR_COUNT_DEFAULT - Static variable in class com.google.cloud.bigtable.config.BulkOptions
For internal use only - public for technical reasons.
BIGTABLE_BATCH_DATA_HOST_DEFAULT - Static variable in class com.google.cloud.bigtable.config.BigtableOptions
For internal use only - public for technical reasons.
BIGTABLE_BULK_AUTOFLUSH_MS_DEFAULT - Static variable in class com.google.cloud.bigtable.config.BulkOptions
The maximum amount of time a row will be buffered for.
BIGTABLE_BULK_ENABLE_THROTTLE_REBALANCE_DEFAULT - Static variable in class com.google.cloud.bigtable.config.BulkOptions
Whether or not to enable a mechanism that reduces the likelihood that a BulkMutation intensive application will overload a cluster.
BIGTABLE_BULK_MAX_REQUEST_SIZE_BYTES_DEFAULT - Static variable in class com.google.cloud.bigtable.config.BulkOptions
This describes the maximum size a bulk mutation RPC should be before sending it to the server and starting the next bulk call.
BIGTABLE_BULK_MAX_ROW_KEY_COUNT_DEFAULT - Static variable in class com.google.cloud.bigtable.config.BulkOptions
This describes the maximum number of individual MutateRowsRequest.Entry objects to bundle in a single bulk mutation RPC before sending it to the server and starting the next bulk call.
BIGTABLE_BULK_THROTTLE_TARGET_MS_DEFAULT - Static variable in class com.google.cloud.bigtable.config.BulkOptions
The target RPC response time for a MutateRows request.
BIGTABLE_CLIENT_ADAPTER - Static variable in class com.google.cloud.bigtable.config.BigtableOptions
Deprecated.
This field will be removed in future versions.
BIGTABLE_DATA_CHANNEL_COUNT_DEFAULT - Static variable in class com.google.cloud.bigtable.config.BigtableOptions
For internal use only - public for technical reasons.
BIGTABLE_DATA_HOST_DEFAULT - Static variable in class com.google.cloud.bigtable.config.BigtableOptions
For internal use only - public for technical reasons.
BIGTABLE_EMULATOR_HOST_ENV_VAR - Static variable in class com.google.cloud.bigtable.config.BigtableOptions
For internal use only - public for technical reasons.
BIGTABLE_MAX_INFLIGHT_RPCS_PER_CHANNEL_DEFAULT - Static variable in class com.google.cloud.bigtable.config.BulkOptions
Default rpc count per channel.
BIGTABLE_MAX_MEMORY_DEFAULT - Static variable in class com.google.cloud.bigtable.config.BulkOptions
This is the maximum accumulated size of uncompleted requests that we allow before throttling.
BIGTABLE_PORT_DEFAULT - Static variable in class com.google.cloud.bigtable.config.BigtableOptions
For internal use only - public for technical reasons.
BIGTABLE_V2_INSTANCE_FMT - Static variable in class com.google.cloud.bigtable.grpc.BigtableInstanceName
Constant BIGTABLE_V2_INSTANCE_FMT="projects/%s/instances/%s"
BigtableAsyncRpc<REQUEST,RESPONSE> - Interface in com.google.cloud.bigtable.grpc.async
This interface represents a logical asynchronous RPC end point, including creating a ClientCall for a new request.
BigtableAsyncRpc.RpcMetrics - Class in com.google.cloud.bigtable.grpc.async
 
BigtableAsyncUtilities - Interface in com.google.cloud.bigtable.grpc.async
Utilities for creating and executing async methods.
BigtableAsyncUtilities.Default - Class in com.google.cloud.bigtable.grpc.async
 
BigtableClientMetrics - Class in com.google.cloud.bigtable.metrics
Singleton Container for a MetricRegistry.
BigtableClientMetrics.MetricLevel - Enum in com.google.cloud.bigtable.metrics
 
BigtableClusterName - Class in com.google.cloud.bigtable.grpc
This class encapsulates a cluster name of the form projects/(projectId)/instances/(instanceId)/clusters/(clusterId)
BigtableClusterName(String) - Constructor for class com.google.cloud.bigtable.grpc.BigtableClusterName
For internal use only - public for technical reasons.
BigtableClusterUtilities - Class in com.google.cloud.bigtable.grpc
This is a utility that can be used to resize a cluster.
BigtableClusterUtilities(BigtableOptions) - Constructor for class com.google.cloud.bigtable.grpc.BigtableClusterUtilities
Constructor for the utility.
BigtableDataClient - Interface in com.google.cloud.bigtable.grpc
Interface to access v2 Bigtable data service methods.
BigtableDataClientWrapper - Class in com.google.cloud.bigtable.grpc
This class implements the IBigtableDataClient interface and wraps BigtableDataClient with Google-cloud-java's models.
BigtableDataClientWrapper(BigtableDataClient, RequestContext) - Constructor for class com.google.cloud.bigtable.grpc.BigtableDataClientWrapper
 
BigtableDataGCJClient - Class in com.google.cloud.bigtable.grpc
This class implements existing IBigtableDataClient operations with Google-cloud-java's BigtableDataClient.
BigtableDataGCJClient(BigtableDataClient) - Constructor for class com.google.cloud.bigtable.grpc.BigtableDataGCJClient
 
BigtableDataGrpcClient - Class in com.google.cloud.bigtable.grpc
A gRPC client to access the v2 Bigtable data service.
BigtableDataGrpcClient(Channel, ScheduledExecutorService, BigtableOptions) - Constructor for class com.google.cloud.bigtable.grpc.BigtableDataGrpcClient
Constructor for BigtableDataGrpcClient.
BigtableInstanceClient - Interface in com.google.cloud.bigtable.grpc
BigtableInstanceClient manages instances and clusters.
BigtableInstanceGrpcClient - Class in com.google.cloud.bigtable.grpc
BigtableInstanceGrpcClient class.
BigtableInstanceGrpcClient(Channel) - Constructor for class com.google.cloud.bigtable.grpc.BigtableInstanceGrpcClient
Constructor for BigtableInstanceGrpcClient.
BigtableInstanceName - Class in com.google.cloud.bigtable.grpc
This class encapsulates a Bigtable instance name.
BigtableInstanceName(String, String) - Constructor for class com.google.cloud.bigtable.grpc.BigtableInstanceName
For internal use only - public for technical reasons.
BigtableOptions - Class in com.google.cloud.bigtable.config
An immutable class providing access to configuration options for Bigtable.
BigtableOptions.Builder - Class in com.google.cloud.bigtable.config
A mutable builder for BigtableConnectionOptions.
BigtableOptions.ChannelConfigurator - Interface in com.google.cloud.bigtable.config
For internal use only - public for technical reasons.
BigtableResultScannerFactory<ResponseT> - Interface in com.google.cloud.bigtable.grpc.scanner
Deprecated.
This class will be removed in the future
BigtableRetriesExhaustedException - Exception in com.google.cloud.bigtable.grpc.scanner
An Exception that is thrown when an operation fails, even in the face of retries.
BigtableRetriesExhaustedException(String, Throwable) - Constructor for exception com.google.cloud.bigtable.grpc.scanner.BigtableRetriesExhaustedException
For internal use only - public for technical reasons.
BigtableSession - Class in com.google.cloud.bigtable.grpc
Encapsulates the creation of Bigtable Grpc services.
BigtableSession(BigtableOptions) - Constructor for class com.google.cloud.bigtable.grpc.BigtableSession
Constructor for BigtableSession.
BigtableSessionSharedThreadPools - Class in com.google.cloud.bigtable.grpc
This class contains executors and other thread pool related resources that can be reused across a few BigtableSessions.
BigtableSessionSharedThreadPools() - Constructor for class com.google.cloud.bigtable.grpc.BigtableSessionSharedThreadPools
 
BigtableSnapshotName - Class in com.google.cloud.bigtable.grpc
Deprecated.
Snapshots will be removed in the future
BigtableSnapshotName(String) - Constructor for class com.google.cloud.bigtable.grpc.BigtableSnapshotName
Deprecated.
 
BigtableTableAdminClient - Interface in com.google.cloud.bigtable.grpc
A client for the Cloud Bigtable Table Admin API.
BigtableTableAdminClientWrapper - Class in com.google.cloud.bigtable.grpc
This class implements the IBigtableTableAdminClient interface and wraps BigtableTableAdminClient with Google-cloud-java's models.
BigtableTableAdminClientWrapper(BigtableTableAdminClient, BigtableOptions) - Constructor for class com.google.cloud.bigtable.grpc.BigtableTableAdminClientWrapper
 
BigtableTableAdminGCJClient - Class in com.google.cloud.bigtable.grpc
This class implements existing IBigtableTableAdminClient operations with Google-cloud-java's BigtableTableAdminClient & BaseBigtableTableAdminClient.
BigtableTableAdminGCJClient(BigtableTableAdminClient, BaseBigtableTableAdminClient) - Constructor for class com.google.cloud.bigtable.grpc.BigtableTableAdminGCJClient
 
BigtableTableAdminGrpcClient - Class in com.google.cloud.bigtable.grpc
A gRPC client for accessing the Bigtable Table Admin API.
BigtableTableAdminGrpcClient(Channel, ScheduledExecutorService, BigtableOptions) - Constructor for class com.google.cloud.bigtable.grpc.BigtableTableAdminGrpcClient
Constructor for BigtableTableAdminGrpcClient.
BigtableTableName - Class in com.google.cloud.bigtable.grpc
This class encapsulates a tableName.
BigtableTableName(String) - Constructor for class com.google.cloud.bigtable.grpc.BigtableTableName
 
BigtableVeneerSettingsFactory - Class in com.google.cloud.bigtable.config
Static methods to convert an instance of BigtableOptions to a BigtableDataSettings or BigtableTableAdminSettings instance .
BigtableVeneerSettingsFactory() - Constructor for class com.google.cloud.bigtable.config.BigtableVeneerSettingsFactory
 
BigtableVersionInfo - Class in com.google.cloud.bigtable.config
For internal use only - public for technical reasons.
BigtableVersionInfo() - Constructor for class com.google.cloud.bigtable.config.BigtableVersionInfo
 
build() - Method in class com.google.cloud.bigtable.config.BigtableOptions.Builder
 
build() - Method in class com.google.cloud.bigtable.config.BulkOptions.Builder
 
build() - Method in class com.google.cloud.bigtable.config.CallOptionsConfig.Builder
 
build() - Method in class com.google.cloud.bigtable.config.RetryOptions.Builder
Construct a new RetryOptions object.
build() - Method in class com.google.cloud.bigtable.grpc.scanner.FlatRow.Builder
 
build() - Method in class com.google.cloud.bigtable.grpc.scanner.FlatRow.Cell.Builder
 
builder() - Static method in class com.google.cloud.bigtable.config.BigtableOptions
Create a new instance of the BigtableOptions.Builder.
Builder() - Constructor for class com.google.cloud.bigtable.config.BigtableOptions.Builder
Deprecated.
Please use the BigtableOptions.builder() instead.
builder() - Static method in class com.google.cloud.bigtable.config.BulkOptions
 
Builder() - Constructor for class com.google.cloud.bigtable.config.BulkOptions.Builder
Deprecated.
builder() - Static method in class com.google.cloud.bigtable.config.CallOptionsConfig
 
Builder() - Constructor for class com.google.cloud.bigtable.config.CallOptionsConfig.Builder
Deprecated.
builder() - Static method in class com.google.cloud.bigtable.config.RetryOptions
 
Builder() - Constructor for class com.google.cloud.bigtable.config.RetryOptions.Builder
Deprecated.
Please use RetryOptions.builder()
Builder(RetryOptions) - Constructor for class com.google.cloud.bigtable.config.RetryOptions.Builder
Deprecated.
Please use RetryOptions.toBuilder()
Builder() - Constructor for class com.google.cloud.bigtable.grpc.scanner.FlatRow.Cell.Builder
 
buildResponse() - Method in class com.google.cloud.bigtable.grpc.async.MutateRowsRequestManager
 
BulkMutation - Class in com.google.cloud.bigtable.grpc.async
This class combines a collection of MutateRowRequests into a single MutateRowsRequest.
BulkMutation(BigtableTableName, BigtableDataClient, ScheduledExecutorService, BulkOptions) - Constructor for class com.google.cloud.bigtable.grpc.async.BulkMutation
For internal use only - public for technical reasons.
BulkMutationGCJClient - Class in com.google.cloud.bigtable.grpc.async
This class is meant to replicate existing BulkMutation while translating calls to * Google-Cloud-Java's Batcher api.
BulkMutationGCJClient(Batcher<RowMutationEntry, Void>) - Constructor for class com.google.cloud.bigtable.grpc.async.BulkMutationGCJClient
 
BulkMutationWrapper - Class in com.google.cloud.bigtable.grpc.async
This class wraps existing BulkMutation with Google-cloud-java's model.
BulkMutationWrapper(BulkMutation) - Constructor for class com.google.cloud.bigtable.grpc.async.BulkMutationWrapper
 
BulkOptions - Class in com.google.cloud.bigtable.config
An immutable class providing access to bulk related configuration options for Bigtable.
BulkOptions.Builder - Class in com.google.cloud.bigtable.config
A mutable builder for BigtableConnectionOptions.
BulkRead - Class in com.google.cloud.bigtable.grpc.async
This class combines a collection of ReadRowsRequests with a single row key into a single ReadRowsRequest with a RowSet which will result in fewer round trips.
BulkRead(IBigtableDataClient, BigtableTableName, int, ExecutorService) - Constructor for class com.google.cloud.bigtable.grpc.async.BulkRead
Constructor for BulkRead.
ByteStringComparator - Class in com.google.cloud.bigtable.util
Compares ByteStrings.
ByteStringComparator() - Constructor for class com.google.cloud.bigtable.util.ByteStringComparator
 

C

calculateTheClosestNextRowKeyForPrefix(byte[]) - Static method in class com.google.cloud.bigtable.util.RowKeyUtil
When scanning for a prefix the scan should stop immediately after the the last row that has the specified prefix.
call(I) - Method in interface com.google.cloud.bigtable.util.ReferenceCountedHashMap.Callable
 
CallController<RequestT,ResponseT> - Class in com.google.cloud.bigtable.grpc.async
Wraps a ClientCall, and implements ClientCallStreamObserver to allow access to the call's underlying functionality.
CallController() - Constructor for class com.google.cloud.bigtable.grpc.async.CallController
 
CallOptionsConfig - Class in com.google.cloud.bigtable.config
Experimental options to turn on timeout options.
CallOptionsConfig(boolean, int, int) - Constructor for class com.google.cloud.bigtable.config.CallOptionsConfig
Deprecated.
CallOptionsConfig.Builder - Class in com.google.cloud.bigtable.config
 
CallOptionsFactory - Interface in com.google.cloud.bigtable.grpc
A factory that creates CallOptions for use in BigtableDataClient RPCs.
CallOptionsFactory.ConfiguredCallOptionsFactory - Class in com.google.cloud.bigtable.grpc
Creates a new CallOptions based on a CallOptionsConfig.
CallOptionsFactory.Default - Class in com.google.cloud.bigtable.grpc
Returns CallOptions.DEFAULT with any Context.current()'s Context.getDeadline() applied to it.
callWrapper - Variable in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation
 
cancel() - Method in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation
Cancels the RPC.
cancel(String) - Method in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation
Cancels the RPC with a specific message.
cancel(String, Throwable) - Method in class com.google.cloud.bigtable.grpc.async.CallController
 
cancel() - Method in interface com.google.cloud.bigtable.grpc.scanner.ScanHandler
Perform an rpc cancellation given a client-side request.
Cell(String, ByteString, long, ByteString, List<String>) - Constructor for class com.google.cloud.bigtable.grpc.scanner.FlatRow.Cell
For internal use only - public for technical reasons.
cellValue(ByteString) - Method in class com.google.cloud.bigtable.grpc.scanner.FlatRowAdapter.FlatRowBuilder
ChannelPool - Class in com.google.cloud.bigtable.grpc.io
Manages a set of ClosableChannels and uses them in a round robin.
ChannelPool(ChannelPool.ChannelFactory, int) - Constructor for class com.google.cloud.bigtable.grpc.io.ChannelPool
Constructor for ChannelPool.
ChannelPool.ChannelFactory - Interface in com.google.cloud.bigtable.grpc.io
A factory for creating ManagedChannels to be used in a ChannelPool.
checkAndMutateRow(ConditionalRowMutation) - Method in interface com.google.cloud.bigtable.core.IBigtableDataClient
Mutate a row atomically dependent on a precondition.
checkAndMutateRow(CheckAndMutateRowRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableDataClient
Mutate a row atomically dependent on a precondition.
checkAndMutateRow(ConditionalRowMutation) - Method in class com.google.cloud.bigtable.grpc.BigtableDataClientWrapper
Mutate a row atomically dependent on a precondition.
checkAndMutateRow(ConditionalRowMutation) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGCJClient
 
checkAndMutateRow(CheckAndMutateRowRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGrpcClient
Mutate a row atomically dependent on a precondition.
checkAndMutateRowAsync(ConditionalRowMutation) - Method in interface com.google.cloud.bigtable.core.IBigtableDataClient
Mutate a row atomically dependent on a precondition.
checkAndMutateRowAsync(CheckAndMutateRowRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableDataClient
Mutate a row atomically dependent on a precondition.
checkAndMutateRowAsync(ConditionalRowMutation) - Method in class com.google.cloud.bigtable.grpc.BigtableDataClientWrapper
Mutate a row atomically dependent on a precondition.
checkAndMutateRowAsync(ConditionalRowMutation) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGCJClient
 
checkAndMutateRowAsync(CheckAndMutateRowRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGrpcClient
Mutate a row atomically dependent on a precondition.
clear() - Method in class com.google.cloud.bigtable.util.ReferenceCountedHashMap
Remove all items from hash map and all references from reference counter.
clearRowInProgress() - Method in class com.google.cloud.bigtable.grpc.scanner.RowMerger
 
CLIENT_VERSION - Static variable in class com.google.cloud.bigtable.config.BigtableVersionInfo
 
clone() - Method in class com.google.cloud.bigtable.config.BigtableOptions
 
clone() - Method in class com.google.cloud.bigtable.config.BulkOptions
 
clone() - Method in class com.google.cloud.bigtable.config.RetryOptions
 
clone() - Method in class com.google.cloud.bigtable.util.ReferenceCountedHashMap
 
close() - Method in interface com.google.cloud.bigtable.core.IBulkMutation
Closes this bulk Mutation and prevents from mutating any more elements
close() - Method in class com.google.cloud.bigtable.grpc.async.BulkMutationGCJClient
 
close() - Method in class com.google.cloud.bigtable.grpc.async.BulkMutationWrapper
 
close() - Method in class com.google.cloud.bigtable.grpc.BigtableClusterUtilities
Shuts down the connection to the admin API.
close() - Method in class com.google.cloud.bigtable.grpc.BigtableDataGCJClient
 
close() - Method in class com.google.cloud.bigtable.grpc.BigtableSession
close() - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGCJClient
 
close() - Method in class com.google.cloud.bigtable.grpc.scanner.ResponseQueueReader
 
close() - Method in class com.google.cloud.bigtable.grpc.scanner.ResumingStreamingResultScanner
close() - Method in class com.google.cloud.bigtable.grpc.scanner.RowResultScanner
 
close() - Method in interface com.google.cloud.bigtable.metrics.Timer.Context
 
CLOUD_BIGTABLE_ADMIN_SCOPE - Static variable in class com.google.cloud.bigtable.config.CredentialFactory
The OAuth scope required to perform administrator actions such as creating tables.
CLOUD_BIGTABLE_ALL_SCOPES - Static variable in class com.google.cloud.bigtable.config.CredentialFactory
Scopes required for full access to cloud bigtable.
CLOUD_BIGTABLE_READ_WRITE_SCOPES - Static variable in class com.google.cloud.bigtable.config.CredentialFactory
Scopes required to read and write data from tables.
CLOUD_BIGTABLE_READER_SCOPE - Static variable in class com.google.cloud.bigtable.config.CredentialFactory
The OAuth scope required to read data from tables.
CLOUD_BIGTABLE_WRITER_SCOPE - Static variable in class com.google.cloud.bigtable.config.CredentialFactory
The OAuth scope required to write data to tables.
com.google.cloud.bigtable.config - package com.google.cloud.bigtable.config
 
com.google.cloud.bigtable.core - package com.google.cloud.bigtable.core
 
com.google.cloud.bigtable.grpc - package com.google.cloud.bigtable.grpc
 
com.google.cloud.bigtable.grpc.async - package com.google.cloud.bigtable.grpc.async
 
com.google.cloud.bigtable.grpc.io - package com.google.cloud.bigtable.grpc.io
 
com.google.cloud.bigtable.grpc.scanner - package com.google.cloud.bigtable.grpc.scanner
 
com.google.cloud.bigtable.metrics - package com.google.cloud.bigtable.metrics
 
com.google.cloud.bigtable.util - package com.google.cloud.bigtable.util
 
compare(ByteString, ByteString) - Method in class com.google.cloud.bigtable.util.ByteStringComparator
 
compareTo(RowKeyWrapper) - Method in class com.google.cloud.bigtable.util.RowKeyWrapper
 
completionFuture - Variable in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation
 
configureChannel(ManagedChannelBuilder, String) - Method in interface com.google.cloud.bigtable.config.BigtableOptions.ChannelConfigurator
 
ConfiguredCallOptionsFactory(CallOptionsConfig) - Constructor for class com.google.cloud.bigtable.grpc.CallOptionsFactory.ConfiguredCallOptionsFactory
 
convert(FlatRow) - Static method in class com.google.cloud.bigtable.grpc.scanner.FlatRowConverter
 
convertToModelRow(FlatRow) - Static method in class com.google.cloud.bigtable.grpc.scanner.FlatRowConverter
 
CORE_USER_AGENT - Static variable in class com.google.cloud.bigtable.config.BigtableVersionInfo
 
counter(BigtableClientMetrics.MetricLevel, String) - Static method in class com.google.cloud.bigtable.metrics.BigtableClientMetrics
Creates a named Counter.
Counter - Interface in com.google.cloud.bigtable.metrics
An incrementing counter metric.
counter(String) - Method in class com.google.cloud.bigtable.metrics.DropwizardMetricRegistry
Creates a named Counter that wraps a Dropwizard Metrics Counter.
counter(String) - Method in interface com.google.cloud.bigtable.metrics.MetricRegistry
Creates a named Counter.
create(MethodDescriptor<RequestT, ?>, RequestT) - Method in class com.google.cloud.bigtable.grpc.CallOptionsFactory.ConfiguredCallOptionsFactory
Creates a CallOptions with a focus on Deadline.
create(MethodDescriptor<RequestT, ?>, RequestT) - Method in interface com.google.cloud.bigtable.grpc.CallOptionsFactory
Provide a CallOptions object to be used in a single RPC.
create(MethodDescriptor<RequestT, ?>, RequestT) - Method in class com.google.cloud.bigtable.grpc.CallOptionsFactory.Default
 
create() - Method in interface com.google.cloud.bigtable.grpc.io.ChannelPool.ChannelFactory
 
createAppProfile(CreateAppProfileRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableInstanceClient
Create an application profile.
createAppProfile(CreateAppProfileRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableInstanceGrpcClient
Create an application profile.
createAsyncRpc(MethodDescriptor<RequestT, ResponseT>, Predicate<RequestT>) - Method in interface com.google.cloud.bigtable.grpc.async.BigtableAsyncUtilities
createAsyncUnaryRpc.
createAsyncRpc(MethodDescriptor<RequestT, ResponseT>, Predicate<RequestT>) - Method in class com.google.cloud.bigtable.grpc.async.BigtableAsyncUtilities.Default
 
createBackupAsync(CreateBackupRequest) - Method in interface com.google.cloud.bigtable.core.IBigtableTableAdminClient
Creates a new backup from a table in a specific cluster.
createBackupAsync(CreateBackupRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableTableAdminClient
Creates a new backup from a table in a specific cluster.
createBackupAsync(CreateBackupRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminClientWrapper
 
createBackupAsync(CreateBackupRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGCJClient
Creates a new backup from a table in a specific cluster.
createBackupAsync(CreateBackupRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGrpcClient
 
createBigtableDataSettings(BigtableOptions) - Static method in class com.google.cloud.bigtable.config.BigtableVeneerSettingsFactory
To create an instance of BigtableDataSettings from BigtableOptions.
createBulkMutation(BigtableTableName) - Method in class com.google.cloud.bigtable.grpc.BigtableSession
createBulkMutation.
createBulkMutationBatcher(String) - Method in interface com.google.cloud.bigtable.core.IBigtableDataClient
Creates IBulkMutation batcher.
createBulkMutationBatcher(String) - Method in class com.google.cloud.bigtable.grpc.BigtableDataClientWrapper
Creates IBulkMutation batcher.
createBulkMutationBatcher(String) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGCJClient
 
createBulkMutationWrapper(BigtableTableName) - Method in class com.google.cloud.bigtable.grpc.BigtableSession
For internal use only - public for technical reasons.
createBulkRead(BigtableTableName) - Method in class com.google.cloud.bigtable.grpc.BigtableSession
createBulkRead.
createCallController() - Method in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation
 
createCallController() - Method in class com.google.cloud.bigtable.grpc.scanner.RetryingReadRowsOperation
 
createChannelPool(String, int) - Method in class com.google.cloud.bigtable.grpc.BigtableSession
Deprecated.
Channel creation is now considered an internal implementation detail channel creation methods will be removed from the public surface in the future
createChannelPool(ChannelPool.ChannelFactory, int) - Method in class com.google.cloud.bigtable.grpc.BigtableSession
Deprecated.
Channel creation is now considered an internal implementation detail channel creation methods will be removed from the public surface in the future
createChannelPool(String, BigtableOptions) - Static method in class com.google.cloud.bigtable.grpc.BigtableSession
Deprecated.
Channel creation is now considered an internal implementation detail channel creation methods will be removed from the public surface in the future
createChannelPool(String, BigtableOptions, int) - Static method in class com.google.cloud.bigtable.grpc.BigtableSession
Deprecated.
Channel creation is now considered an internal implementation detail channel creation methods will be removed in the future
createCluster(CreateClusterRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableInstanceClient
Create an instance within a project.
createCluster(CreateClusterRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableInstanceGrpcClient
Create an instance within a project.
createInstance(CreateInstanceRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableInstanceClient
Create an instance within a project.
createInstance(CreateInstanceRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableInstanceGrpcClient
Create an instance within a project.
createInstanceClient(BigtableOptions) - Static method in class com.google.cloud.bigtable.grpc.BigtableSession
Deprecated.
createManagedPool(String, int) - Method in class com.google.cloud.bigtable.grpc.BigtableSession
Deprecated.
Channel creation is now considered an internal implementation detail channel creation methods will be removed from the public surface in the future
createNettyChannel(String, BigtableOptions, ClientInterceptor...) - Static method in class com.google.cloud.bigtable.grpc.BigtableSession
For internal use only - public for technical reasons.
createRowBuilder() - Method in class com.google.cloud.bigtable.grpc.scanner.FlatRowAdapter
createRpcMetrics(MethodDescriptor<?, ?>) - Static method in class com.google.cloud.bigtable.grpc.async.BigtableAsyncRpc.RpcMetrics
 
createScanMarkerRow(ByteString) - Method in class com.google.cloud.bigtable.grpc.scanner.FlatRowAdapter.FlatRowBuilder
createScanner(ReadRowsRequest) - Method in interface com.google.cloud.bigtable.grpc.scanner.BigtableResultScannerFactory
Deprecated.
Create a scanner for the given request.
createSlf4jReporter(DropwizardMetricRegistry, Logger, long, TimeUnit) - Static method in class com.google.cloud.bigtable.metrics.DropwizardMetricRegistry
Creates a DropwizardMetricRegistry with an Slf4jReporter.
createTable(CreateTableRequest) - Method in interface com.google.cloud.bigtable.core.IBigtableTableAdminClient
Creates a new table.
createTable(CreateTableRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableTableAdminClient
Creates a new table.
createTable(CreateTableRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminClientWrapper
Creates a new table.
createTable(CreateTableRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGCJClient
Creates a new table.
createTable(CreateTableRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGrpcClient
Creates a new table.
createTableAdminSettings(BigtableOptions) - Static method in class com.google.cloud.bigtable.config.BigtableVeneerSettingsFactory
To create an instance of BigtableTableAdminSettings from BigtableOptions.
createTableAsync(CreateTableRequest) - Method in interface com.google.cloud.bigtable.core.IBigtableTableAdminClient
Creates a new table asynchronously.
createTableAsync(CreateTableRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableTableAdminClient
Creates a new table asynchronously.
createTableAsync(CreateTableRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminClientWrapper
Creates a new table asynchronously.
createTableAsync(CreateTableRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGCJClient
Creates a new table asynchronously.
createTableAsync(CreateTableRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGrpcClient
Creates a new table asynchronously.
createTableFromSnapshotAsync(CreateTableFromSnapshotRequest) - Method in interface com.google.cloud.bigtable.core.IBigtableTableAdminClient
Deprecated.
this will be removed in a future release - please use backups API instead
createTableFromSnapshotAsync(CreateTableFromSnapshotRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableTableAdminClient
Deprecated.
Snapshots will be removed in the future
createTableFromSnapshotAsync(CreateTableFromSnapshotRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminClientWrapper
 
createTableFromSnapshotAsync(CreateTableFromSnapshotRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGCJClient
Creates a new table from a snapshot.
createTableFromSnapshotAsync(CreateTableFromSnapshotRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGrpcClient
credential(Credentials) - Static method in class com.google.cloud.bigtable.config.CredentialOptions
A CredentialOption that wraps an existing Credentials object.
CredentialFactory - Class in com.google.cloud.bigtable.config
Simple factory for creating OAuth Credential objects for use with Bigtable.
CredentialFactory() - Constructor for class com.google.cloud.bigtable.config.CredentialFactory
 
CredentialInterceptorCache - Class in com.google.cloud.bigtable.grpc.io
Caches RefreshingOAuth2CredentialsInterceptor for default authorization cases.
CredentialOptions - Class in com.google.cloud.bigtable.config
This class encapsulates the method the Cloud Bigtable client should use to look up Credentials.
CredentialOptions.CredentialType - Enum in com.google.cloud.bigtable.config
 
CredentialOptions.JsonCredentialsOptions - Class in com.google.cloud.bigtable.config
A CredentialOption that has a json credentials configured as an InputStream instead of a system environment property.
CredentialOptions.P12CredentialOptions - Class in com.google.cloud.bigtable.config
A CredentialOptions defined by a serviceAccount and a p12 key file.
CredentialOptions.UserSuppliedCredentialOptions - Class in com.google.cloud.bigtable.config
A CredentialOption that supplies the Credentials directly.

D

debug(String, Object...) - Method in class com.google.cloud.bigtable.config.Logger
debug
debug(String, Throwable, Object...) - Method in class com.google.cloud.bigtable.config.Logger
debug
dec() - Method in interface com.google.cloud.bigtable.metrics.Counter
 
Default(Channel) - Constructor for class com.google.cloud.bigtable.grpc.async.BigtableAsyncUtilities.Default
 
Default() - Constructor for class com.google.cloud.bigtable.grpc.CallOptionsFactory.Default
 
DEFAULT_BACKOFF_MULTIPLIER - Static variable in class com.google.cloud.bigtable.config.RetryOptions
Multiplier to apply to wait times after failed retries (default value: 1.5).
DEFAULT_ENABLE_GRPC_RETRIES - Static variable in class com.google.cloud.bigtable.config.RetryOptions
Flag indicating whether or not grpc retries should be enabled.
DEFAULT_ENABLE_GRPC_RETRIES_SET - Static variable in class com.google.cloud.bigtable.config.RetryOptions
For internal use only - public for technical reasons.
DEFAULT_INITIAL_BACKOFF_MILLIS - Static variable in class com.google.cloud.bigtable.config.RetryOptions
Initial amount of time to wait before retrying failed operations (default value: 5ms).
DEFAULT_MAX_ELAPSED_BACKOFF_MILLIS - Static variable in class com.google.cloud.bigtable.config.RetryOptions
Maximum amount of time to retry before failing the operation (default value: 60 seconds).
DEFAULT_MAX_SCAN_TIMEOUT_RETRIES - Static variable in class com.google.cloud.bigtable.config.RetryOptions
Maximum number of times to retry after a scan timeout
DEFAULT_READ_PARTIAL_ROW_TIMEOUT_MS - Static variable in class com.google.cloud.bigtable.config.RetryOptions
We can timeout when reading large cells with a low value here.
DEFAULT_STREAMING_BUFFER_SIZE - Static variable in class com.google.cloud.bigtable.config.RetryOptions
Deprecated.
This field will be removed in the future
defaultCredentials() - Static method in class com.google.cloud.bigtable.config.CredentialOptions
Use the Application Default Credentials which are credentials that identify and authorize the whole application.
deleteAppProfile(DeleteAppProfileRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableInstanceClient
Delete an application profile.
deleteAppProfile(DeleteAppProfileRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableInstanceGrpcClient
Delete an application profile.
deleteBackupAsync(String, String) - Method in interface com.google.cloud.bigtable.core.IBigtableTableAdminClient
Permanently deletes the specified backup.
deleteBackupAsync(DeleteBackupRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableTableAdminClient
Permanently deletes the specified backup.
deleteBackupAsync(String, String) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminClientWrapper
 
deleteBackupAsync(String, String) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGCJClient
Permanently deletes the specified backup.
deleteBackupAsync(DeleteBackupRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGrpcClient
 
deleteCluster(DeleteClusterRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableInstanceClient
Deletes a cluster from an instance.
deleteCluster(DeleteClusterRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableInstanceGrpcClient
Deletes a cluster from an instance.
deleteInstance(DeleteInstanceRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableInstanceClient
Updates an instance within a project.
deleteInstance(DeleteInstanceRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableInstanceGrpcClient
Updates an instance within a project.
deleteSnapshotAsync(DeleteSnapshotRequest) - Method in interface com.google.cloud.bigtable.core.IBigtableTableAdminClient
Deprecated.
this will be removed in a future release - please use backups API instead
deleteSnapshotAsync(DeleteSnapshotRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableTableAdminClient
Deprecated.
Snapshots will be removed in the future
deleteSnapshotAsync(DeleteSnapshotRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminClientWrapper
 
deleteSnapshotAsync(DeleteSnapshotRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGCJClient
Permanently deletes the specified snapshot.
deleteSnapshotAsync(DeleteSnapshotRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGrpcClient
deleteTable(String) - Method in interface com.google.cloud.bigtable.core.IBigtableTableAdminClient
Permanently deletes a specified table and all of its data.
deleteTable(DeleteTableRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableTableAdminClient
Permanently deletes a specified table and all of its data.
deleteTable(String) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminClientWrapper
Permanently deletes a specified table and all of its data.
deleteTable(String) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGCJClient
Permanently deletes a specified table and all of its data.
deleteTable(DeleteTableRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGrpcClient
Permanently deletes a specified table and all of its data.
deleteTableAsync(String) - Method in interface com.google.cloud.bigtable.core.IBigtableTableAdminClient
Permanently deletes a specified table and all of its data.
deleteTableAsync(DeleteTableRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableTableAdminClient
Permanently deletes a specified table and all of its data.
deleteTableAsync(String) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminClientWrapper
Permanently deletes a specified table and all of its data.
deleteTableAsync(String) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGCJClient
Permanently deletes a specified table and all of its data.
deleteTableAsync(DeleteTableRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGrpcClient
Permanently deletes a specified table and all of its data.
disableAutoInboundFlowControl() - Method in class com.google.cloud.bigtable.grpc.async.CallController
Disable automatic calls to ClientCall.request(int), and the user will explicitly request more results using CallController.request(int).
dropAllRows(String) - Method in interface com.google.cloud.bigtable.core.IBigtableTableAdminClient
Drops all data in the table.
dropAllRows(String) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminClientWrapper
 
dropAllRows(String) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGCJClient
Drops all data in the table.
dropAllRowsAsync(String) - Method in interface com.google.cloud.bigtable.core.IBigtableTableAdminClient
Asynchronously drops all data in the table
dropAllRowsAsync(String) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminClientWrapper
 
dropAllRowsAsync(String) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGCJClient
Asynchronously drops all data in the table
dropRowRange(String, String) - Method in interface com.google.cloud.bigtable.core.IBigtableTableAdminClient
Permanently deletes all rows in a range.
dropRowRange(String, ByteString) - Method in interface com.google.cloud.bigtable.core.IBigtableTableAdminClient
Permanently deletes all rows in a range.
dropRowRange(DropRowRangeRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableTableAdminClient
Permanently deletes all rows in a range.
dropRowRange(String, String) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminClientWrapper
Permanently deletes all rows in a range.
dropRowRange(String, ByteString) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminClientWrapper
Permanently deletes all rows in a range.
dropRowRange(String, String) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGCJClient
Permanently deletes all rows in a range.
dropRowRange(String, ByteString) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGCJClient
Permanently deletes all rows in a range.
dropRowRange(DropRowRangeRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGrpcClient
Permanently deletes all rows in a range.
dropRowRangeAsync(String, String) - Method in interface com.google.cloud.bigtable.core.IBigtableTableAdminClient
Permanently deletes all rows in a range.
dropRowRangeAsync(String, ByteString) - Method in interface com.google.cloud.bigtable.core.IBigtableTableAdminClient
Permanently deletes all rows in a range.
dropRowRangeAsync(DropRowRangeRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableTableAdminClient
Permanently deletes all rows in a range.
dropRowRangeAsync(String, String) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminClientWrapper
Permanently deletes all rows in a range.
dropRowRangeAsync(String, ByteString) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminClientWrapper
Permanently deletes all rows in a range.
dropRowRangeAsync(String, String) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGCJClient
Permanently deletes all rows in a range.
dropRowRangeAsync(String, ByteString) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGCJClient
Permanently deletes all rows in a range.
dropRowRangeAsync(DropRowRangeRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGrpcClient
Permanently deletes all rows in a range.
DropwizardMetricRegistry - Class in com.google.cloud.bigtable.metrics
A MetricRegistry that wraps a Dropwizard Metrics MetricRegistry.
DropwizardMetricRegistry() - Constructor for class com.google.cloud.bigtable.metrics.DropwizardMetricRegistry
 
DropwizardMetricRegistry(MetricRegistry) - Constructor for class com.google.cloud.bigtable.metrics.DropwizardMetricRegistry
 

E

enableBulkMutationThrottling() - Method in class com.google.cloud.bigtable.config.BulkOptions.Builder
Deprecated.
This will be removed in the future
enableEmulator(String) - Method in class com.google.cloud.bigtable.config.BigtableOptions.Builder
 
enableEmulator(String, int) - Method in class com.google.cloud.bigtable.config.BigtableOptions.Builder
 
enableRetries() - Method in class com.google.cloud.bigtable.config.RetryOptions
Enable or disable retries.
equals(Object) - Method in class com.google.cloud.bigtable.config.BigtableOptions
equals(Object) - Method in class com.google.cloud.bigtable.config.BulkOptions
equals(Object) - Method in class com.google.cloud.bigtable.config.CallOptionsConfig
equals(Object) - Method in class com.google.cloud.bigtable.config.CredentialOptions
equals(Object) - Method in class com.google.cloud.bigtable.config.CredentialOptions.JsonCredentialsOptions
 
equals(Object) - Method in class com.google.cloud.bigtable.config.CredentialOptions.P12CredentialOptions
 
equals(Object) - Method in class com.google.cloud.bigtable.config.CredentialOptions.UserSuppliedCredentialOptions
 
equals(Object) - Method in class com.google.cloud.bigtable.config.RetryOptions
equals(Object) - Method in class com.google.cloud.bigtable.grpc.scanner.FlatRow.Cell
 
equals(Object) - Method in class com.google.cloud.bigtable.grpc.scanner.FlatRow
 
error(String, Object...) - Method in class com.google.cloud.bigtable.config.Logger
error
error(String, Throwable, Object...) - Method in class com.google.cloud.bigtable.config.Logger
error
extractIdentifier(Metadata) - Static method in class com.google.cloud.bigtable.grpc.io.ChannelPool
For internal use only - public for technical reasons.

F

failedCount - Variable in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation
 
fatal(String, Object...) - Method in class com.google.cloud.bigtable.config.Logger
fatal
fatal(String, Throwable, Object...) - Method in class com.google.cloud.bigtable.config.Logger
fatal
finalizeStats(Status) - Method in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation
 
finalizeStats(Status) - Method in class com.google.cloud.bigtable.grpc.scanner.RetryingReadRowsOperation
 
finishCell() - Method in class com.google.cloud.bigtable.grpc.scanner.FlatRowAdapter.FlatRowBuilder
Adds a Cell to FlatRow.Cell's map which is ordered by family.
finishRow() - Method in class com.google.cloud.bigtable.grpc.scanner.FlatRowAdapter.FlatRowBuilder
This method flattens the FlatRowAdapter.FlatRowBuilder.cells which has a map of Lists keyed by family name.
FlatRow - Class in com.google.cloud.bigtable.grpc.scanner
This class stores represents a single row.
FlatRow(ByteString, ImmutableList<FlatRow.Cell>) - Constructor for class com.google.cloud.bigtable.grpc.scanner.FlatRow
For internal use only - public for technical reasons.
FlatRow.Builder - Class in com.google.cloud.bigtable.grpc.scanner
For internal use only - public for technical reasons.
FlatRow.Cell - Class in com.google.cloud.bigtable.grpc.scanner
 
FlatRow.Cell.Builder - Class in com.google.cloud.bigtable.grpc.scanner
For internal use only - public for technical reasons.
FlatRowAdapter - Class in com.google.cloud.bigtable.grpc.scanner
Adapter for RowAdapter that uses FlatRow's to represent logical rows.
FlatRowAdapter() - Constructor for class com.google.cloud.bigtable.grpc.scanner.FlatRowAdapter
 
FlatRowAdapter.FlatRowBuilder - Class in com.google.cloud.bigtable.grpc.scanner
 
FlatRowBuilder() - Constructor for class com.google.cloud.bigtable.grpc.scanner.FlatRowAdapter.FlatRowBuilder
 
FlatRowConverter - Class in com.google.cloud.bigtable.grpc.scanner
This class converts between instances of FlatRow and Row.
FlatRowConverter() - Constructor for class com.google.cloud.bigtable.grpc.scanner.FlatRowConverter
 
flush() - Method in interface com.google.cloud.bigtable.core.IBulkMutation
Sends any outstanding RowMutationEntry and blocks until all requests are complete.
flush() - Method in class com.google.cloud.bigtable.grpc.async.BulkMutation
Send any outstanding MutateRowRequests and wait until all requests are complete.
flush() - Method in class com.google.cloud.bigtable.grpc.async.BulkMutationGCJClient
Sends any outstanding RowMutationEntry and blocks until all requests are complete.
flush() - Method in class com.google.cloud.bigtable.grpc.async.BulkMutationWrapper
Sends any outstanding RowMutationEntry and blocks until all requests are complete.
flush() - Method in class com.google.cloud.bigtable.grpc.async.BulkRead
Sends all remaining requests to the server.
forAllInstances(String) - Static method in class com.google.cloud.bigtable.grpc.BigtableClusterUtilities
Creates a BigtableClusterUtilities for all instances in a projectId.
forInstance(String, String) - Static method in class com.google.cloud.bigtable.grpc.BigtableClusterUtilities
Creates a BigtableClusterUtilities for a projectId and an instanceId.

G

getAbsoluteMaxInFlightRpcs() - Method in class com.google.cloud.bigtable.grpc.async.ResourceLimiter
Getter for the field maxInFlightRpcs.
getAdminHost() - Method in class com.google.cloud.bigtable.config.BigtableOptions
Getter for the field tableAdminHost.
getApplicationDefaultCredential() - Static method in class com.google.cloud.bigtable.config.CredentialFactory
Initializes OAuth2 application default credentials based on the environment the code is running in.
getAppProfile(GetAppProfileRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableInstanceClient
Get an application profile.
getAppProfile(GetAppProfileRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableInstanceGrpcClient
Get an application profile.
getAppProfileId() - Method in class com.google.cloud.bigtable.config.BigtableOptions
Getter for the field appProfileId.
getAsyncMutatorCount() - Method in class com.google.cloud.bigtable.config.BulkOptions
Getter for the field asyncMutatorCount.
getAsyncResult() - Method in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation
Initial execution of the RPC.
getAutoflushMs() - Method in class com.google.cloud.bigtable.config.BulkOptions
Getter for the field autoflushMs.
getBackoffMultiplier() - Method in class com.google.cloud.bigtable.config.RetryOptions
Multiplier we will apply to backoff times between retries.
getBackupAsync(String, String) - Method in interface com.google.cloud.bigtable.core.IBigtableTableAdminClient
Gets metadata information about the specified backup.
getBackupAsync(GetBackupRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableTableAdminClient
Gets metadata information about the specified backup.
getBackupAsync(String, String) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminClientWrapper
 
getBackupAsync(String, String) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGCJClient
Gets metadata information about the specified backup.
getBackupAsync(GetBackupRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGrpcClient
 
getBatchSizes() - Method in class com.google.cloud.bigtable.grpc.async.BulkRead
For internal use only - public for technical reasons.
getBatchThreadPool() - Method in class com.google.cloud.bigtable.grpc.BigtableSessionSharedThreadPools
Getter for the field batchThreadPool.
getBlockingResult() - Method in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation
 
getBulkMaxRequestSize() - Method in class com.google.cloud.bigtable.config.BulkOptions
Getter for the field bulkMaxRequestSize.
getBulkMaxRowKeyCount() - Method in class com.google.cloud.bigtable.config.BulkOptions
Getter for the field bulkMaxRowKeyCount.
getBulkMutationRpcTargetMs() - Method in class com.google.cloud.bigtable.config.BulkOptions
if BulkOptions.isEnableBulkMutationThrottling(), then bulk mutation RPC latency will be compared against this value.
getBulkOptions() - Method in class com.google.cloud.bigtable.config.BigtableOptions
Getter for the field bulkOptions.
getCachedClientContexts() - Method in class com.google.cloud.bigtable.grpc.BigtableSession
Getter for the field cachedClientContexts.
getCachedCredentials() - Method in class com.google.cloud.bigtable.config.CredentialOptions.JsonCredentialsOptions
 
getCallOptionsConfig() - Method in class com.google.cloud.bigtable.config.BigtableOptions
Getter for the field callOptionsConfig.
getCells() - Method in class com.google.cloud.bigtable.grpc.scanner.FlatRow
 
getChannelConfigurator() - Method in class com.google.cloud.bigtable.config.BigtableOptions
For internal use only - public for technical reasons.
getChannelCount() - Method in class com.google.cloud.bigtable.config.BigtableOptions
The number of data channels to create.
getCluster(String, String) - Method in class com.google.cloud.bigtable.grpc.BigtableClusterUtilities
Gets the current configuration of the cluster as encapsulated by a Cluster object.
getCluster(GetClusterRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableInstanceClient
Gets information about a cluster.
getCluster(GetClusterRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableInstanceGrpcClient
Gets information about a cluster.
getClusterId() - Method in class com.google.cloud.bigtable.grpc.BigtableClusterName
 
getClusterId() - Method in class com.google.cloud.bigtable.grpc.BigtableSnapshotName
Deprecated.
 
getClusterName() - Method in class com.google.cloud.bigtable.grpc.BigtableClusterName
 
getClusterName() - Method in class com.google.cloud.bigtable.grpc.BigtableSession
Snapshot operations need various aspects of a BigtableClusterName.
getClusterNodeCount(String, String) - Method in class com.google.cloud.bigtable.grpc.BigtableClusterUtilities
Gets the current number of nodes allocated to the cluster.
getClusters() - Method in class com.google.cloud.bigtable.grpc.BigtableClusterUtilities
Gets a ListClustersResponse that contains all of the clusters for the projectId/instanceId configuration.
getClusterSize(String, String) - Method in class com.google.cloud.bigtable.grpc.BigtableClusterUtilities
getClusterSize() - Method in class com.google.cloud.bigtable.grpc.BigtableClusterUtilities
Gets the serve node count of an instance with a single cluster.
getCredential() - Method in class com.google.cloud.bigtable.config.CredentialOptions.UserSuppliedCredentialOptions
 
getCredentialFromPrivateKeyServiceAccount(String, String) - Static method in class com.google.cloud.bigtable.config.CredentialFactory
Initializes OAuth2 credential from a private keyfile, as described in Service accounts.
getCredentialFromPrivateKeyServiceAccount(String, String, List<String>) - Static method in class com.google.cloud.bigtable.config.CredentialFactory
Initializes OAuth2 credential from a private keyfile, as described in Service accounts.
getCredentialOptions() - Method in class com.google.cloud.bigtable.config.BigtableOptions
Get the credential this object was constructed with.
getCredentials(CredentialOptions) - Static method in class com.google.cloud.bigtable.config.CredentialFactory
Look up a Credentials object based on a configuration of credentials described in a CredentialOptions.
getCredentialsInterceptor(CredentialOptions, RetryOptions) - Method in class com.google.cloud.bigtable.grpc.io.CredentialInterceptorCache
Given CredentialOptions that define how to look up credentials, do the following: Look up the credentials If there are credentials, create a gRPC interceptor that gets OAuth2 security tokens and add that token as a header on all calls.
getCredentialType() - Method in class com.google.cloud.bigtable.config.CredentialOptions
Getter for the field credentialType.
getCumulativeThrottlingTimeNanos() - Method in class com.google.cloud.bigtable.grpc.async.ResourceLimiterStats
 
getCurrentInFlightMaxRpcs() - Method in class com.google.cloud.bigtable.grpc.async.ResourceLimiter
Getter for the field currentInFlightMaxRpcs.
getDataChannelCount() - Method in class com.google.cloud.bigtable.config.BigtableOptions.Builder
For internal use only - public for technical reasons.
getDataClient() - Method in class com.google.cloud.bigtable.grpc.BigtableSession
Getter for the field dataClient.
getDataClientWrapper() - Method in class com.google.cloud.bigtable.grpc.BigtableSession
Getter for the field clientWrapper.
getDataHost() - Method in class com.google.cloud.bigtable.config.BigtableOptions
Getter for the field dataHost.
getDefaultOptions() - Static method in class com.google.cloud.bigtable.config.BigtableOptions
 
getDefaultOptions() - Static method in class com.google.cloud.bigtable.config.RetryOptions
 
getEnvJsonFile() - Static method in class com.google.cloud.bigtable.config.CredentialOptions
Get a configured json credentials file from the GOOGLE_APPLICATION_CREDENTIALS environment variable.
getExhaustedRetriesException(Status) - Method in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation
 
getFamily() - Method in class com.google.cloud.bigtable.grpc.scanner.FlatRow.Cell
 
getHeapSize() - Method in class com.google.cloud.bigtable.grpc.async.ResourceLimiter
getHeapSize.
getHttpTransportFactory() - Static method in class com.google.cloud.bigtable.config.CredentialFactory
 
getIamPolicy(GetIamPolicyRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableInstanceClient
Get an IAM policy.
getIamPolicy(GetIamPolicyRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableInstanceGrpcClient
Get an IAM policy.
getIamPolicy(GetIamPolicyRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableTableAdminClient
Get an IAM policy.
getIamPolicy(GetIamPolicyRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGrpcClient
Get an IAM policy.
getInitialBackoffMillis() - Method in class com.google.cloud.bigtable.config.RetryOptions
The amount of time in milliseconds we will wait for our first error retry.
getInputStream() - Method in class com.google.cloud.bigtable.config.CredentialOptions.JsonCredentialsOptions
 
getInputStreamCredential(InputStream) - Static method in class com.google.cloud.bigtable.config.CredentialFactory
Initializes OAuth2 application default credentials based on an inputStream.
getInstance(BigtableInstanceName) - Static method in class com.google.cloud.bigtable.grpc.async.ResourceLimiterStats
 
getInstance() - Static method in class com.google.cloud.bigtable.grpc.BigtableSessionSharedThreadPools
Get the shared instance of ThreadPools.
getInstance() - Static method in class com.google.cloud.bigtable.grpc.io.CredentialInterceptorCache
Getter for the field instance.
getInstanceAdminClient() - Method in class com.google.cloud.bigtable.grpc.BigtableSession
Getter for the field instanceAdminClient.
getInstanceId() - Method in class com.google.cloud.bigtable.config.BigtableOptions
Getter for the field instanceId.
getInstanceId() - Method in class com.google.cloud.bigtable.grpc.BigtableClusterName
 
getInstanceId() - Method in class com.google.cloud.bigtable.grpc.BigtableInstanceName
 
getInstanceId() - Method in class com.google.cloud.bigtable.grpc.BigtableSnapshotName
Deprecated.
 
getInstanceId() - Method in class com.google.cloud.bigtable.grpc.BigtableTableName
 
getInstanceName() - Method in class com.google.cloud.bigtable.config.BigtableOptions
Getter for the field instanceName.
getInstanceName() - Method in class com.google.cloud.bigtable.grpc.BigtableInstanceName
 
getKey(FlatRow) - Method in class com.google.cloud.bigtable.grpc.scanner.FlatRowAdapter
getKey() - Method in class com.google.cloud.bigtable.util.RowKeyWrapper
 
getKeyFile() - Method in class com.google.cloud.bigtable.config.CredentialOptions.P12CredentialOptions
P12 file - https://developers.google.com/identity/protocols/OAuth2ServiceAccount
getLabels() - Method in class com.google.cloud.bigtable.grpc.scanner.FlatRow.Cell
 
getLastCompletedRowKey() - Method in class com.google.cloud.bigtable.grpc.scanner.RowMerger
 
getLevel() - Method in enum com.google.cloud.bigtable.metrics.BigtableClientMetrics.MetricLevel
 
getLevelToLog() - Static method in class com.google.cloud.bigtable.metrics.BigtableClientMetrics
 
getLog() - Method in class com.google.cloud.bigtable.config.Logger
Get the underlying Log
getLongRpcTimeoutMs() - Method in class com.google.cloud.bigtable.config.CallOptionsConfig
getMaxElapsedBackoffMillis() - Method in class com.google.cloud.bigtable.config.RetryOptions
Maximum amount of time we will retry an operation that is failing.
getMaxHeapSize() - Method in class com.google.cloud.bigtable.grpc.async.ResourceLimiter
Getter for the field maxHeapSize.
getMaxInflightRpcs() - Method in class com.google.cloud.bigtable.config.BulkOptions
Getter for the field maxInflightRpcs.
getMaxMemory() - Method in class com.google.cloud.bigtable.config.BulkOptions
Getter for the field maxMemory.
getMaxScanTimeoutRetries() - Method in class com.google.cloud.bigtable.config.RetryOptions
The maximum number of times to retry after a scan timeout.
getMethodDescriptor() - Method in interface com.google.cloud.bigtable.grpc.async.BigtableAsyncRpc
getMethodDescriptor.
getMetricRegistry(BigtableClientMetrics.MetricLevel) - Static method in class com.google.cloud.bigtable.metrics.BigtableClientMetrics
 
getMutateRpcTimeoutMs() - Method in class com.google.cloud.bigtable.config.CallOptionsConfig
Getter for the field mutateRpcTimeoutMs.
getMutationTimer() - Method in class com.google.cloud.bigtable.grpc.async.ResourceLimiterStats
 
getNext() - Method in class com.google.cloud.bigtable.grpc.scanner.ResponseQueueReader
getNext.
getNextBackoff() - Method in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation
 
getNextMergedRow() - Method in class com.google.cloud.bigtable.grpc.scanner.ResponseQueueReader
Get the next complete FlatRow object from the response queue.
getOperation(GetOperationRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableInstanceClient
Gets the latest state of a long-running operation.
getOperation(GetOperationRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableInstanceGrpcClient
Gets the latest state of a long-running operation.
getOperation(GetOperationRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableTableAdminClient
Gets the latest state of a long-running operation.
getOperation(GetOperationRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGrpcClient
Gets the latest state of a long-running operation.
getOperation(GetOperationRequest) - Method in class com.google.cloud.bigtable.util.OperationUtil
 
getOperationCallOptions() - Method in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation
Returns the CallOptions that a user set for the entire Operation, which can span multiple RPCs/retries.
getOptions() - Method in class com.google.cloud.bigtable.grpc.BigtableSession
Getter for the field options.
getPort() - Method in class com.google.cloud.bigtable.config.BigtableOptions
Getter for the field port.
getProjectId() - Method in class com.google.cloud.bigtable.config.BigtableOptions
Getter for the field projectId.
getProjectId() - Method in class com.google.cloud.bigtable.grpc.BigtableInstanceName
 
getProjectId() - Method in class com.google.cloud.bigtable.grpc.BigtableTableName
 
getQualifier() - Method in class com.google.cloud.bigtable.grpc.scanner.FlatRow.Cell
 
getReadPartialRowTimeoutMillis() - Method in class com.google.cloud.bigtable.config.RetryOptions
A timeout for reading individual ReadRowsResponse messages from a stream.
getReadStreamRpcTimeoutMs() - Method in class com.google.cloud.bigtable.config.CallOptionsConfig
Getter for the field readStreamRpcTimeoutMs.
getRegistry() - Method in class com.google.cloud.bigtable.metrics.DropwizardMetricRegistry
 
getRetryableStatusCodes() - Method in class com.google.cloud.bigtable.config.RetryOptions
Returns Set of Status.Code that allow RPC retries.
getRetryExecutor() - Method in class com.google.cloud.bigtable.grpc.BigtableSessionSharedThreadPools
Getter for the field retryExecutor.
getRetryOptions() - Method in class com.google.cloud.bigtable.config.BigtableOptions
Options controlling retries.
getRetryRequest() - Method in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation
 
getRetryRequest() - Method in class com.google.cloud.bigtable.grpc.async.MutateRowsRequestManager
 
getRetryRequest() - Method in class com.google.cloud.bigtable.grpc.async.RetryingMutateRowsOperation
 
getRetryRequest() - Method in class com.google.cloud.bigtable.grpc.scanner.RetryingReadRowsOperation
Updates the original request via ReadRowsRequestManager.buildUpdatedRequest().
getRowCountInLastMessage() - Method in class com.google.cloud.bigtable.grpc.scanner.RowMerger
 
getRowKey() - Method in class com.google.cloud.bigtable.grpc.scanner.FlatRow.Builder
 
getRowKey() - Method in class com.google.cloud.bigtable.grpc.scanner.FlatRow
 
getRpcCallOptions() - Method in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation
Create an CallOptions that has a fail safe RPC deadline to make sure that unary operations don't hang.
getRpcMetrics() - Method in interface com.google.cloud.bigtable.grpc.async.BigtableAsyncRpc
 
getRunnable() - Method in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation
 
getServiceAccount() - Method in class com.google.cloud.bigtable.config.CredentialOptions.P12CredentialOptions
ServiceAccount email address used for the P12 file - https://developers.google.com/identity/protocols/OAuth2ServiceAccount
getShortRpcTimeoutMs() - Method in class com.google.cloud.bigtable.config.CallOptionsConfig
Getter for the field shortRpcTimeoutMs.
getSingleCluster() - Method in class com.google.cloud.bigtable.grpc.BigtableClusterUtilities
 
getSnapshotAsync(GetSnapshotRequest) - Method in interface com.google.cloud.bigtable.core.IBigtableTableAdminClient
Deprecated.
this will be removed in a future release - please use backups API instead
getSnapshotAsync(GetSnapshotRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableTableAdminClient
Deprecated.
Snapshots will be removed in the future
getSnapshotAsync(GetSnapshotRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminClientWrapper
 
getSnapshotAsync(GetSnapshotRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGCJClient
Gets metadata information about the specified snapshot.
getSnapshotAsync(GetSnapshotRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGrpcClient
getSnapshotId() - Method in class com.google.cloud.bigtable.grpc.BigtableSnapshotName
Deprecated.
 
getSnapshotName() - Method in class com.google.cloud.bigtable.grpc.BigtableSnapshotName
Deprecated.
 
getState() - Method in exception com.google.cloud.bigtable.grpc.io.Watchdog.StreamWaitTimeoutException
 
getStats() - Static method in class com.google.cloud.bigtable.grpc.io.ChannelPool
 
getStatus() - Method in exception com.google.cloud.bigtable.grpc.io.IOExceptionWithStatus
Status from the provided OperationRuntimeException.
getStreamingBufferSize() - Method in class com.google.cloud.bigtable.config.RetryOptions
Deprecated.
This getter will be removed in the future
getTable(String) - Method in interface com.google.cloud.bigtable.core.IBigtableTableAdminClient
Gets the details of a table.
getTable(GetTableRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableTableAdminClient
Gets the details of a table.
getTable(String) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminClientWrapper
Gets the details of a table.
getTable(String) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGCJClient
Gets the details of a table.
getTable(GetTableRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGrpcClient
Gets the details of a table.
getTableAdminClient() - Method in class com.google.cloud.bigtable.grpc.BigtableSession
Getter for the field tableAdminClient.
getTableAdminClientWrapper() - Method in class com.google.cloud.bigtable.grpc.BigtableSession
Initializes bigtableTableAdminClient based on flag to use GCJ adapter, available in BigtableOptions.
getTableAsync(String) - Method in interface com.google.cloud.bigtable.core.IBigtableTableAdminClient
Gets the details of a table asynchronously.
getTableAsync(GetTableRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableTableAdminClient
Gets the details of a table asynchronously.
getTableAsync(String) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminClientWrapper
Gets the details of a table asynchronously.
getTableAsync(String) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGCJClient
Gets the details of a table asynchronously.
getTableAsync(GetTableRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGrpcClient
Gets the details of a table asynchronously.
getTableId() - Method in class com.google.cloud.bigtable.grpc.BigtableTableName
 
getThreadFactory(String, boolean) - Static method in class com.google.cloud.bigtable.util.ThreadUtil
Get a ThreadFactory suitable for use in the current environment.
getThrottlingTimer() - Method in class com.google.cloud.bigtable.grpc.async.ResourceLimiterStats
 
getTimeoutMs() - Method in class com.google.cloud.bigtable.config.CallOptionsConfig
Deprecated.
getTimestamp() - Method in class com.google.cloud.bigtable.grpc.scanner.FlatRow.Cell
 
getUserAgent() - Method in class com.google.cloud.bigtable.config.BigtableOptions
Gets the user-agent to be appended to User-Agent header when creating new streams for the channel.
getValue() - Method in class com.google.cloud.bigtable.grpc.scanner.FlatRow.Cell
 
getWaitTimeMs() - Method in exception com.google.cloud.bigtable.grpc.io.Watchdog.StreamWaitTimeoutException
 
getZoneId(Cluster) - Static method in class com.google.cloud.bigtable.grpc.BigtableClusterUtilities
 
GoogleCloudResourcePrefixInterceptor - Class in com.google.cloud.bigtable.grpc.io
Adds a header ("google-cloud-resource-prefix") that usually contains a fully qualified instance or table name.
GoogleCloudResourcePrefixInterceptor(String) - Constructor for class com.google.cloud.bigtable.grpc.io.GoogleCloudResourcePrefixInterceptor
Constructor for GoogleCloudResourcePrefixInterceptor.
GRPC_RESOURCE_PREFIX_KEY - Static variable in class com.google.cloud.bigtable.grpc.io.GoogleCloudResourcePrefixInterceptor
Constant GRPC_RESOURCE_PREFIX_KEY
GrpcFuture() - Constructor for class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation.GrpcFuture
 

H

hasInflightOperations() - Method in class com.google.cloud.bigtable.grpc.async.OperationAccountant
hasInflightRequests.
hasInflightRequests() - Method in class com.google.cloud.bigtable.grpc.async.ResourceLimiter
hasInflightRequests.
hasStatusBeenRecieved() - Method in class com.google.cloud.bigtable.grpc.scanner.StreamObserverAdapter
Deprecated.
 
HeaderInterceptor - Class in com.google.cloud.bigtable.grpc.io
Adds a header ("google-cloud-resource-prefix") that usually contains a fully qualified instance or table name.
HeaderInterceptor(Metadata.Key<String>, String) - Constructor for class com.google.cloud.bigtable.grpc.io.HeaderInterceptor
Constructor for GoogleCloudResourcePrefixInterceptor.

I

IBigtableDataClient - Interface in com.google.cloud.bigtable.core
Interface to wrap BigtableDataClient with Google-Cloud-java's models.
IBigtableTableAdminClient - Interface in com.google.cloud.bigtable.core
Interface to wrap BigtableTableAdminClient with Google-Cloud-java's models.
IBulkMutation - Interface in com.google.cloud.bigtable.core
Interface to support batching multiple RowMutationEntry request into a single grpc * request.
inc() - Method in interface com.google.cloud.bigtable.metrics.Counter
 
info(String, Object...) - Method in class com.google.cloud.bigtable.config.Logger
info
info(String, Throwable, Object...) - Method in class com.google.cloud.bigtable.config.Logger
info
inRetryMode() - Method in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation
 
INSTANCE - Static variable in class com.google.cloud.bigtable.util.ByteStringComparator
 
interceptCall(MethodDescriptor<ReqT, RespT>, CallOptions, Channel) - Method in class com.google.cloud.bigtable.grpc.async.ThrottlingClientInterceptor
 
interceptCall(MethodDescriptor<ReqT, RespT>, CallOptions, Channel) - Method in class com.google.cloud.bigtable.grpc.io.HeaderInterceptor
interceptCall(MethodDescriptor<ReqT, RespT>, CallOptions, Channel) - Method in class com.google.cloud.bigtable.grpc.io.RefreshingOAuth2CredentialsInterceptor
interceptCall(MethodDescriptor<ReqT, RespT>, CallOptions, Channel) - Method in class com.google.cloud.bigtable.grpc.io.WatchdogInterceptor
 
interruptTask() - Method in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation.GrpcFuture
This gets called from Future.cancel(boolean) for cancel(true).
IOExceptionWithStatus - Exception in com.google.cloud.bigtable.grpc.io
An IOException that carries a gRPC Status object.
IOExceptionWithStatus(String, Throwable, Status) - Constructor for exception com.google.cloud.bigtable.grpc.io.IOExceptionWithStatus
Constructor for IOExceptionWithStatus.
IOExceptionWithStatus(String, Status) - Constructor for exception com.google.cloud.bigtable.grpc.io.IOExceptionWithStatus
Constructor for IOExceptionWithStatus.
IS_RETRYABLE_MUTATION - Static variable in class com.google.cloud.bigtable.grpc.BigtableDataGrpcClient
Constant IS_RETRYABLE_MUTATION
isAutoFlowControlEnabled() - Method in class com.google.cloud.bigtable.grpc.async.CallController
 
isDirectPathEnabled() - Static method in class com.google.cloud.bigtable.config.BigtableOptions
Checks if DirectPath is enabled via an environment variable.
isEnableBulkMutationThrottling() - Method in class com.google.cloud.bigtable.config.BulkOptions
Is an experimental feature of throttling bulk mutation RPCs turned on?
isEnabled(BigtableClientMetrics.MetricLevel) - Static method in class com.google.cloud.bigtable.metrics.BigtableClientMetrics
Checks if a BigtableClientMetrics.MetricLevel is enabled;
isFlushed() - Method in class com.google.cloud.bigtable.grpc.async.BulkMutation
 
isFull() - Method in class com.google.cloud.bigtable.grpc.async.ResourceLimiter
isFull.
isGet(ReadRowsRequest) - Static method in class com.google.cloud.bigtable.grpc.CallOptionsFactory.ConfiguredCallOptionsFactory
 
isLongRequest(Object) - Static method in class com.google.cloud.bigtable.grpc.CallOptionsFactory.ConfiguredCallOptionsFactory
Deprecated.
isReady() - Method in class com.google.cloud.bigtable.grpc.async.CallController
 
isRequestRetryable() - Method in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation
 
isRequestRetryable() - Method in class com.google.cloud.bigtable.grpc.scanner.RetryingReadRowsOperation
All read rows requests are retryable.
isRetryable(Status.Code) - Method in class com.google.cloud.bigtable.config.RetryOptions
Determines if the RPC should be retried based on the input Status.Code.
isRetryable(REQUEST) - Method in interface com.google.cloud.bigtable.grpc.async.BigtableAsyncRpc
Can this request be retried?
isScanMarkerRow(FlatRow) - Method in class com.google.cloud.bigtable.grpc.scanner.FlatRowAdapter
isShutdown() - Method in class com.google.cloud.bigtable.grpc.io.ChannelPool
isStreamingRead() - Method in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation
 
isTerminated() - Method in class com.google.cloud.bigtable.grpc.io.ChannelPool
isUseTimeout() - Method in class com.google.cloud.bigtable.config.CallOptionsConfig
isUseTimeout.

J

JDK_VERSION - Static variable in class com.google.cloud.bigtable.config.BigtableVersionInfo
 
jsonCredentials(InputStream) - Static method in class com.google.cloud.bigtable.config.CredentialOptions
jsonCredentials.
jsonCredentials(String) - Static method in class com.google.cloud.bigtable.config.CredentialOptions
jsonCredentials.
JsonCredentialsOptions(InputStream) - Constructor for class com.google.cloud.bigtable.config.CredentialOptions.JsonCredentialsOptions
 

L

listAppProfiles(ListAppProfilesRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableInstanceClient
List application profiles.
listAppProfiles(ListAppProfilesRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableInstanceGrpcClient
List application profiles.
listBackupsAsync(String) - Method in interface com.google.cloud.bigtable.core.IBigtableTableAdminClient
Lists all backups associated with the specified cluster.
listBackupsAsync(ListBackupsRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableTableAdminClient
Lists all backups associated with the specified cluster.
listBackupsAsync(String) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminClientWrapper
 
listBackupsAsync(String) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGCJClient
Lists all backups associated with the specified cluster.
listBackupsAsync(ListBackupsRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGrpcClient
 
listCluster(ListClustersRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableInstanceClient
Lists information about clusters in an instance.
listCluster(ListClustersRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableInstanceGrpcClient
Lists information about clusters in an instance.
listInstances(ListInstancesRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableInstanceClient
Lists all instances in the given project.
listInstances(ListInstancesRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableInstanceGrpcClient
Lists all instances in the given project.
listSnapshotsAsync(ListSnapshotsRequest) - Method in interface com.google.cloud.bigtable.core.IBigtableTableAdminClient
Deprecated.
this will be removed in a future release - please use backups API instead
listSnapshotsAsync(ListSnapshotsRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableTableAdminClient
Deprecated.
Snapshots will be removed in the future
listSnapshotsAsync(ListSnapshotsRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminClientWrapper
 
listSnapshotsAsync(ListSnapshotsRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGCJClient
Lists all snapshots associated with the specified cluster.
listSnapshotsAsync(ListSnapshotsRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGrpcClient
listTables() - Method in interface com.google.cloud.bigtable.core.IBigtableTableAdminClient
Lists the names of all tables in an instance.
listTables(ListTablesRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableTableAdminClient
Lists the names of all tables in an instance.
listTables() - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminClientWrapper
Lists the names of all tables in an instance.
listTables() - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGCJClient
Lists the names of all tables in an instance.
listTables(ListTablesRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGrpcClient
Lists the names of all tables in an instance.
listTablesAsync() - Method in interface com.google.cloud.bigtable.core.IBigtableTableAdminClient
Lists the names of all tables in an instance asynchronously.
listTablesAsync(ListTablesRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableTableAdminClient
Lists the names of all tables in an instance asynchronously.
listTablesAsync() - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminClientWrapper
Lists the names of all tables in an instance asynchronously.
listTablesAsync() - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGCJClient
Lists the names of all tables in an instance asynchronously.
listTablesAsync(ListTablesRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGrpcClient
Lists the names of all tables in an instance asynchronously.
LOG - Static variable in class com.google.cloud.bigtable.config.CredentialOptions
Constant LOG
log - Variable in class com.google.cloud.bigtable.config.Logger
 
LOG - Static variable in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation
Constant LOG
LOG - Static variable in class com.google.cloud.bigtable.grpc.async.BulkRead
Constant LOG
LOG - Static variable in class com.google.cloud.bigtable.grpc.io.ChannelPool
Constant LOG
LOG - Static variable in class com.google.cloud.bigtable.grpc.scanner.RowMerger
 
Logger - Class in com.google.cloud.bigtable.config
Wrapper around Log to conditionally format messages if a specified log level is enabled.
Logger(Class<?>) - Constructor for class com.google.cloud.bigtable.config.Logger
Constructor for Logger.
LONG_TIMEOUT_MS_DEFAULT - Static variable in class com.google.cloud.bigtable.config.CallOptionsConfig
The default duration to wait before timing out RPCs.
lookupCluster(String, String) - Static method in class com.google.cloud.bigtable.grpc.BigtableClusterUtilities
 
lookupInstanceId(String, String, String) - Static method in class com.google.cloud.bigtable.grpc.BigtableClusterUtilities
 

M

mark() - Method in interface com.google.cloud.bigtable.metrics.Meter
 
mark(long) - Method in interface com.google.cloud.bigtable.metrics.Meter
 
markCanBeCompleted(long) - Method in class com.google.cloud.bigtable.grpc.async.ResourceLimiter
Mark an operation id, as returned by registerOperationWithHeapSize, as complete
markFailure() - Method in class com.google.cloud.bigtable.grpc.async.BigtableAsyncRpc.RpcMetrics
 
markRetriesExhasted() - Method in class com.google.cloud.bigtable.grpc.async.BigtableAsyncRpc.RpcMetrics
 
markRetry() - Method in class com.google.cloud.bigtable.grpc.async.BigtableAsyncRpc.RpcMetrics
 
MAX_NUMBER_OF_MUTATIONS - Static variable in class com.google.cloud.bigtable.grpc.async.BulkMutation
For internal use only - public for technical reasons.
MAX_RPC_WAIT_TIME_NANOS - Static variable in class com.google.cloud.bigtable.grpc.async.BulkMutation
For internal use only - public for technical reasons.
meter(BigtableClientMetrics.MetricLevel, String) - Static method in class com.google.cloud.bigtable.metrics.BigtableClientMetrics
Creates a named Meter.
meter(String) - Method in class com.google.cloud.bigtable.metrics.DropwizardMetricRegistry
Creates a named Meter that wraps a Dropwizard Metrics Meter.
Meter - Interface in com.google.cloud.bigtable.metrics
A meter metric which measures mean throughput and one-, five-, and fifteen-minute exponentially-weighted moving average throughputs.
meter(String) - Method in interface com.google.cloud.bigtable.metrics.MetricRegistry
Creates a named Meter.
MetricRegistry - Interface in com.google.cloud.bigtable.metrics
A registry of metric instances.
modifyColumnFamily(ModifyColumnFamiliesRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableTableAdminClient
Creates, modifies or deletes a new column family within a specified table.
modifyColumnFamily(ModifyColumnFamiliesRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGrpcClient
Creates, modifies or deletes a new column family within a specified table.
modifyColumnFamilyAsync(ModifyColumnFamiliesRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableTableAdminClient
Creates, modifies or deletes a new column family within a specified table.
modifyColumnFamilyAsync(ModifyColumnFamiliesRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGrpcClient
Creates, modifies or deletes a new column family within a specified table.
modifyFamilies(ModifyColumnFamiliesRequest) - Method in interface com.google.cloud.bigtable.core.IBigtableTableAdminClient
Creates, modifies or deletes a new column family within a specified table.
modifyFamilies(ModifyColumnFamiliesRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminClientWrapper
Creates, modifies or deletes a new column family within a specified table.
modifyFamilies(ModifyColumnFamiliesRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGCJClient
Creates, modifies or deletes a new column family within a specified table.
modifyFamiliesAsync(ModifyColumnFamiliesRequest) - Method in interface com.google.cloud.bigtable.core.IBigtableTableAdminClient
Creates, modifies or deletes a new column family within a specified table.
modifyFamiliesAsync(ModifyColumnFamiliesRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminClientWrapper
Creates, modifies or deletes a new column family within a specified table.
modifyFamiliesAsync(ModifyColumnFamiliesRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGCJClient
Creates, modifies or deletes a new column family within a specified table.
mutateRow(RowMutation) - Method in interface com.google.cloud.bigtable.core.IBigtableDataClient
Mutate a row atomically.
mutateRow(MutateRowRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableDataClient
Mutate a row atomically.
mutateRow(RowMutation) - Method in class com.google.cloud.bigtable.grpc.BigtableDataClientWrapper
Mutate a row atomically.
mutateRow(RowMutation) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGCJClient
 
mutateRow(MutateRowRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGrpcClient
Mutate a row atomically.
mutateRowAsync(RowMutation) - Method in interface com.google.cloud.bigtable.core.IBigtableDataClient
Mutate a row atomically.
mutateRowAsync(MutateRowRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableDataClient
Mutate a row atomically.
mutateRowAsync(RowMutation) - Method in class com.google.cloud.bigtable.grpc.BigtableDataClientWrapper
Mutate a row atomically.
mutateRowAsync(RowMutation) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGCJClient
 
mutateRowAsync(MutateRowRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGrpcClient
Mutate a row atomically.
mutateRows(MutateRowsRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableDataClient
Mutates multiple rows in a batch.
mutateRows(MutateRowsRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGrpcClient
Mutates multiple rows in a batch.
mutateRowsAsync(MutateRowsRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableDataClient
Mutates multiple rows in a batch.
mutateRowsAsync(MutateRowsRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGrpcClient
Mutates multiple rows in a batch.
MutateRowsRequestManager - Class in com.google.cloud.bigtable.grpc.async
Performs retries for BigtableDataClient.mutateRows(MutateRowsRequest) operations.
MutateRowsRequestManager(RetryOptions, MutateRowsRequest) - Constructor for class com.google.cloud.bigtable.grpc.async.MutateRowsRequestManager
 
MutateRowsRequestManager.ProcessingStatus - Enum in com.google.cloud.bigtable.grpc.async
 

N

newBuilder() - Static method in class com.google.cloud.bigtable.grpc.scanner.FlatRow.Cell
For internal use only - public for technical reasons.
newBuilder() - Static method in class com.google.cloud.bigtable.grpc.scanner.FlatRow
For internal use only - public for technical reasons.
newCall(CallOptions) - Method in interface com.google.cloud.bigtable.grpc.async.BigtableAsyncRpc
Creates a ClientCall it.
newCall(MethodDescriptor<ReqT, RespT>, CallOptions) - Method in class com.google.cloud.bigtable.grpc.io.ChannelPool
next() - Method in interface com.google.cloud.bigtable.grpc.scanner.ResultScanner
Read the next row and block until a row is available.
next(int) - Method in interface com.google.cloud.bigtable.grpc.scanner.ResultScanner
Read the next N rows where N <= count.
next(int) - Method in class com.google.cloud.bigtable.grpc.scanner.ResumingStreamingResultScanner
Read the next N rows where N <= count.
next() - Method in class com.google.cloud.bigtable.grpc.scanner.ResumingStreamingResultScanner
Read the next row and block until a row is available.
next() - Method in class com.google.cloud.bigtable.grpc.scanner.RowResultScanner
 
next(int) - Method in class com.google.cloud.bigtable.grpc.scanner.RowResultScanner
 
NULL_METRICS_REGISTRY - Static variable in interface com.google.cloud.bigtable.metrics.MetricRegistry
An implementation of MetricRegistry that doesn't actually track metrics, but doesn't throw a NullPointerException.
nullCredential() - Static method in class com.google.cloud.bigtable.config.CredentialOptions
No credentials - used for unit testing.

O

OAuthCredentialsCache - Class in com.google.cloud.bigtable.grpc.io
This class caches calls to OAuth2Credentials.refreshAccessToken().
OAuthCredentialsCache(ExecutorService, OAuth2Credentials) - Constructor for class com.google.cloud.bigtable.grpc.io.OAuthCredentialsCache
Constructor for RefreshingOAuth2CredentialsInterceptor.
onClose(Status, Metadata) - Method in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation
onClose(Status, Metadata) - Method in class com.google.cloud.bigtable.grpc.scanner.OutstandingRequestCountListener
Deprecated.
onClose(Status, Metadata) - Method in class com.google.cloud.bigtable.grpc.scanner.RetryingReadRowsOperation
onClose(Status, Metadata) - Method in class com.google.cloud.bigtable.grpc.scanner.StreamObserverAdapter
Deprecated.
onCompleted() - Method in class com.google.cloud.bigtable.grpc.async.CallController
 
onCompleted() - Method in class com.google.cloud.bigtable.grpc.scanner.ResponseQueueReader
onCompleted() - Method in class com.google.cloud.bigtable.grpc.scanner.RowMerger
onError(Status, Metadata) - Method in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation
 
onError(Throwable) - Method in class com.google.cloud.bigtable.grpc.async.CallController
 
onError(Throwable) - Method in class com.google.cloud.bigtable.grpc.scanner.ResponseQueueReader
onError(Throwable) - Method in class com.google.cloud.bigtable.grpc.scanner.RowMerger
onMessage(MutateRowsResponse) - Method in class com.google.cloud.bigtable.grpc.async.MutateRowsRequestManager
Adds the content of the message to the MutateRowsRequestManager.results.
onMessage(MutateRowsResponse) - Method in class com.google.cloud.bigtable.grpc.async.RetryingMutateRowsOperation
 
onMessage(ResponseT) - Method in class com.google.cloud.bigtable.grpc.async.RetryingStreamOperation
onMessage(ResponseT) - Method in class com.google.cloud.bigtable.grpc.async.RetryingUnaryOperation
onMessage(ResponseT) - Method in class com.google.cloud.bigtable.grpc.scanner.OutstandingRequestCountListener
Deprecated.
onMessage(ReadRowsResponse) - Method in class com.google.cloud.bigtable.grpc.scanner.RetryingReadRowsOperation
onMessage(T) - Method in class com.google.cloud.bigtable.grpc.scanner.StreamObserverAdapter
Deprecated.
onNext(RequestT) - Method in class com.google.cloud.bigtable.grpc.async.CallController
 
onNext(FlatRow) - Method in class com.google.cloud.bigtable.grpc.scanner.ResponseQueueReader
onNext(ReadRowsResponse) - Method in class com.google.cloud.bigtable.grpc.scanner.RowMerger
onOK(Metadata) - Method in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation
A subclass has the opportunity to perform the final operations it needs now that the RPC is successfully complete.
onOK() - Method in class com.google.cloud.bigtable.grpc.async.MutateRowsRequestManager
This is called when all calls to MutateRowsRequestManager.onMessage(MutateRowsResponse) are complete.
onOK(Metadata) - Method in class com.google.cloud.bigtable.grpc.async.RetryingMutateRowsOperation
 
onOK(Metadata) - Method in class com.google.cloud.bigtable.grpc.async.RetryingStreamOperation
A subclass has the opportunity to perform the final operations it needs now that the RPC is successfully complete.
onOK(Metadata) - Method in class com.google.cloud.bigtable.grpc.async.RetryingUnaryOperation
A subclass has the opportunity to perform the final operations it needs now that the RPC is successfully complete.
onOK(Metadata) - Method in class com.google.cloud.bigtable.grpc.scanner.RetryingReadRowsOperation
A subclass has the opportunity to perform the final operations it needs now that the RPC is successfully complete.
OperationAccountant - Class in com.google.cloud.bigtable.grpc.async
Throttles the number of operations that are outstanding at any point in time.
OperationAccountant() - Constructor for class com.google.cloud.bigtable.grpc.async.OperationAccountant
Constructor for OperationAccountant.
operationSpan - Variable in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation
 
operationTimerContext - Variable in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation
 
OperationUtil - Class in com.google.cloud.bigtable.util
 
OperationUtil(OperationsGrpc.OperationsBlockingStub) - Constructor for class com.google.cloud.bigtable.util.OperationUtil
 
OutstandingRequestCountListener<ResponseT> - Class in com.google.cloud.bigtable.grpc.scanner
Deprecated.
This class will be removed in the future
OutstandingRequestCountListener(StreamObserver<ResponseT>, AtomicInteger) - Constructor for class com.google.cloud.bigtable.grpc.scanner.OutstandingRequestCountListener
Deprecated.
Constructor for OutstandingRequestCountListener.

P

p12Credential(String, String) - Static method in class com.google.cloud.bigtable.config.CredentialOptions
Initializes OAuth2 credential from a private keyfile, as described in Service accounts.
partialUpdateInstance(PartialUpdateInstanceRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableInstanceClient
Partially updates an instance within a project.
partialUpdateInstance(PartialUpdateInstanceRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableInstanceGrpcClient
Partially updates an instance within a project.
performRetry(long) - Method in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation
 
performRetry(long) - Method in class com.google.cloud.bigtable.grpc.scanner.RetryingReadRowsOperation
 
put(K, V) - Method in class com.google.cloud.bigtable.util.ReferenceCountedHashMap
Put inserts a key-value pair into the map.
putAll(Map<? extends K, ? extends V>) - Method in class com.google.cloud.bigtable.util.ReferenceCountedHashMap
 

R

readFlatRows(Query) - Method in interface com.google.cloud.bigtable.core.IBigtableDataClient
Perform a scan over FlatRows, in key order.
readFlatRows(ReadRowsRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableDataClient
Perform a scan over FlatRows, in key order.
readFlatRows(ReadRowsRequest, StreamObserver<FlatRow>) - Method in interface com.google.cloud.bigtable.grpc.BigtableDataClient
Perform a streaming read of FlatRows in key order.
readFlatRows(Query) - Method in class com.google.cloud.bigtable.grpc.BigtableDataClientWrapper
Perform a scan over FlatRows, in key order.
readFlatRows(Query) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGCJClient
 
readFlatRows(ReadRowsRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGrpcClient
Perform a scan over FlatRows, in key order.
readFlatRows(ReadRowsRequest, StreamObserver<FlatRow>) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGrpcClient
Perform a streaming read of FlatRows in key order.
readFlatRowsAsync(Query) - Method in interface com.google.cloud.bigtable.core.IBigtableDataClient
Read multiple FlatRows into an in-memory list, in key order.
readFlatRowsAsync(Query, StreamObserver<FlatRow>) - Method in interface com.google.cloud.bigtable.core.IBigtableDataClient
Read FlatRow asynchronously, and pass them to a stream observer to be processed.
readFlatRowsAsync(ReadRowsRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableDataClient
Read multiple FlatRows into an in-memory list, in key order.
readFlatRowsAsync(Query) - Method in class com.google.cloud.bigtable.grpc.BigtableDataClientWrapper
Read multiple FlatRows into an in-memory list, in key order.
readFlatRowsAsync(Query, StreamObserver<FlatRow>) - Method in class com.google.cloud.bigtable.grpc.BigtableDataClientWrapper
Read FlatRow asynchronously, and pass them to a stream observer to be processed.
readFlatRowsAsync(Query) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGCJClient
 
readFlatRowsAsync(Query, StreamObserver<FlatRow>) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGCJClient
 
readFlatRowsAsync(ReadRowsRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGrpcClient
Read multiple FlatRows into an in-memory list, in key order.
readFlatRowsList(Query) - Method in interface com.google.cloud.bigtable.core.IBigtableDataClient
Returns a list of FlatRows, in key order.
readFlatRowsList(ReadRowsRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableDataClient
Returns a list of FlatRows, in key order.
readFlatRowsList(Query) - Method in class com.google.cloud.bigtable.grpc.BigtableDataClientWrapper
Returns a list of FlatRows, in key order.
readFlatRowsList(Query) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGCJClient
 
readFlatRowsList(ReadRowsRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGrpcClient
Returns a list of FlatRows, in key order.
readModifyWriteRow(ReadModifyWriteRow) - Method in interface com.google.cloud.bigtable.core.IBigtableDataClient
Perform an atomic read-modify-write operation on a row.
readModifyWriteRow(ReadModifyWriteRowRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableDataClient
Perform an atomic read-modify-write operation on a row.
readModifyWriteRow(ReadModifyWriteRow) - Method in class com.google.cloud.bigtable.grpc.BigtableDataClientWrapper
Perform an atomic read-modify-write operation on a row.
readModifyWriteRow(ReadModifyWriteRow) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGCJClient
 
readModifyWriteRow(ReadModifyWriteRowRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGrpcClient
Perform an atomic read-modify-write operation on a row.
readModifyWriteRowAsync(ReadModifyWriteRow) - Method in interface com.google.cloud.bigtable.core.IBigtableDataClient
Perform an atomic read-modify-write operation on a row.
readModifyWriteRowAsync(ReadModifyWriteRowRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableDataClient
Perform an atomic read-modify-write operation on a row,
readModifyWriteRowAsync(ReadModifyWriteRow) - Method in class com.google.cloud.bigtable.grpc.BigtableDataClientWrapper
Perform an atomic read-modify-write operation on a row.
readModifyWriteRowAsync(ReadModifyWriteRow) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGCJClient
 
readModifyWriteRowAsync(ReadModifyWriteRowRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGrpcClient
Perform an atomic read-modify-write operation on a row,
readRows(Query) - Method in interface com.google.cloud.bigtable.core.IBigtableDataClient
Perform a scan over Rows, in key order.
readRows(ReadRowsRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableDataClient
Perform a scan over Rows, in key order.
readRows(Query) - Method in class com.google.cloud.bigtable.grpc.BigtableDataClientWrapper
Perform a scan over Rows, in key order.
readRows(Query) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGCJClient
 
readRows(ReadRowsRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGrpcClient
Perform a scan over Rows, in key order.
readRowsAsync(Query) - Method in interface com.google.cloud.bigtable.core.IBigtableDataClient
Read multiple Rows into an in-memory list, in key order.
readRowsAsync(ReadRowsRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableDataClient
Read multiple Rows into an in-memory list, in key order.
readRowsAsync(Query) - Method in class com.google.cloud.bigtable.grpc.BigtableDataClientWrapper
Read multiple Rows into an in-memory list, in key order.
readRowsAsync(Query) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGCJClient
 
readRowsAsync(ReadRowsRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGrpcClient
Read multiple Rows into an in-memory list, in key order.
ReferenceCountedHashMap<K,V> - Class in com.google.cloud.bigtable.util
Allows for a HashMap to reference-count its contents.
ReferenceCountedHashMap() - Constructor for class com.google.cloud.bigtable.util.ReferenceCountedHashMap
Constructor for ReferenceCountedHashMap.
ReferenceCountedHashMap(ReferenceCountedHashMap.Callable<V>) - Constructor for class com.google.cloud.bigtable.util.ReferenceCountedHashMap
Constructor for ReferenceCountedHashMap wth a destructor callable.
ReferenceCountedHashMap.Callable<I> - Interface in com.google.cloud.bigtable.util
Interface for destructor code.
RefreshingOAuth2CredentialsInterceptor - Class in com.google.cloud.bigtable.grpc.io
Client interceptor that authenticates all calls by binding header data provided by a credential.
RefreshingOAuth2CredentialsInterceptor(ExecutorService, OAuth2Credentials) - Constructor for class com.google.cloud.bigtable.grpc.io.RefreshingOAuth2CredentialsInterceptor
Constructor for RefreshingOAuth2CredentialsInterceptor.
registerOperation(ListenableFuture<?>) - Method in class com.google.cloud.bigtable.grpc.async.OperationAccountant
Register a new RPC operation.
registerOperationWithHeapSize(long) - Method in class com.google.cloud.bigtable.grpc.async.ResourceLimiter
Register an operation with the given size before sending.
remove(Object) - Method in class com.google.cloud.bigtable.util.ReferenceCountedHashMap
Remove removes a reference to the key within the context of the reference count.
request(int) - Method in class com.google.cloud.bigtable.grpc.async.CallController
 
reset() - Method in class com.google.cloud.bigtable.grpc.scanner.FlatRowAdapter.FlatRowBuilder
resetStatusBasedBackoff() - Method in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation
Either a response was found, or a timeout event occurred.
ResourceLimiter - Class in com.google.cloud.bigtable.grpc.async
This class limits access by RPCs to system resources
ResourceLimiter(ResourceLimiterStats, long, int) - Constructor for class com.google.cloud.bigtable.grpc.async.ResourceLimiter
Constructor for ResourceLimiter.
ResourceLimiterStats - Class in com.google.cloud.bigtable.grpc.async
This class tracks timing and counts of mutations performed by BulkMutation and throttling performed by ResourceLimiter.
ResourceLimiterStats() - Constructor for class com.google.cloud.bigtable.grpc.async.ResourceLimiterStats
 
ResponseQueueReader - Class in com.google.cloud.bigtable.grpc.scanner
Manages a queue of ResultQueueEntrys of FlatRow.
ResponseQueueReader() - Constructor for class com.google.cloud.bigtable.grpc.scanner.ResponseQueueReader
Constructor for ResponseQueueReader.
restoreTableAsync(RestoreTableRequest) - Method in interface com.google.cloud.bigtable.core.IBigtableTableAdminClient
Creates a new table from a backup.
restoreTableAsync(RestoreTableRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableTableAdminClient
Creates a new table from a backup.
restoreTableAsync(RestoreTableRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminClientWrapper
 
restoreTableAsync(RestoreTableRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGCJClient
Creates a new table from a backup.
restoreTableAsync(RestoreTableRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGrpcClient
 
ResultScanner<T> - Interface in com.google.cloud.bigtable.grpc.scanner
A scanner of Bigtable rows.
ResumingStreamingResultScanner - Class in com.google.cloud.bigtable.grpc.scanner
A ResultScanner that attempts to resume the readRows call when it encounters gRPC INTERNAL errors.
ResumingStreamingResultScanner(ResponseQueueReader) - Constructor for class com.google.cloud.bigtable.grpc.scanner.ResumingStreamingResultScanner
Constructor for ResumingStreamingResultScanner.
RETRY_THREAD_COUNT - Static variable in class com.google.cloud.bigtable.grpc.BigtableSessionSharedThreadPools
Number of threads to use to initiate retry calls
retryExecutor - Variable in class com.google.cloud.bigtable.grpc.BigtableSessionSharedThreadPools
Used for a few cases that benefit from retries, such as puts, gets and scans.
retryExecutorService - Variable in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation
 
RetryingMutateRowsOperation - Class in com.google.cloud.bigtable.grpc.async
Performs retries for BigtableDataClient.mutateRows(MutateRowsRequest) operations.
RetryingMutateRowsOperation(RetryOptions, MutateRowsRequest, BigtableAsyncRpc<MutateRowsRequest, MutateRowsResponse>, CallOptions, ScheduledExecutorService, Metadata, ApiClock) - Constructor for class com.google.cloud.bigtable.grpc.async.RetryingMutateRowsOperation
 
RetryingReadRowsOperation - Class in com.google.cloud.bigtable.grpc.scanner
An extension of AbstractRetryingOperation that manages retries for the readRows streaming RPC.
RetryingReadRowsOperation(StreamObserver<FlatRow>, RetryOptions, ReadRowsRequest, BigtableAsyncRpc<ReadRowsRequest, ReadRowsResponse>, CallOptions, ScheduledExecutorService, Metadata, ApiClock) - Constructor for class com.google.cloud.bigtable.grpc.scanner.RetryingReadRowsOperation
 
RetryingStreamOperation<RequestT,ResponseT> - Class in com.google.cloud.bigtable.grpc.async
An extension of AbstractRetryingOperation that aggregates all responses from a streaming request into a List.
RetryingStreamOperation(RetryOptions, RequestT, BigtableAsyncRpc<RequestT, ResponseT>, CallOptions, ScheduledExecutorService, Metadata, ApiClock) - Constructor for class com.google.cloud.bigtable.grpc.async.RetryingStreamOperation
Constructor for RetryingCollectingClientCallListener.
RetryingUnaryOperation<RequestT,ResponseT> - Class in com.google.cloud.bigtable.grpc.async
A AbstractRetryingOperation for a unary operation.
RetryingUnaryOperation(RetryOptions, RequestT, BigtableAsyncRpc<RequestT, ResponseT>, CallOptions, ScheduledExecutorService, Metadata, ApiClock) - Constructor for class com.google.cloud.bigtable.grpc.async.RetryingUnaryOperation
Constructor for RetryingUnaryRpcListener.
retryOnDeadlineExceeded() - Method in class com.google.cloud.bigtable.config.RetryOptions
Whether to retry on deadline exceeded.
RetryOptions - Class in com.google.cloud.bigtable.config
Options for retrying requests, including back off configuration.
RetryOptions(boolean, boolean, int, double, int, int, int, int, Set<Status.Code>) - Constructor for class com.google.cloud.bigtable.config.RetryOptions
Deprecated.
Please use RetryOptions.builder()
retryOptions - Variable in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation
 
RetryOptions.Builder - Class in com.google.cloud.bigtable.config
A Builder for ChannelOptions objects.
RowKeyUtil - Class in com.google.cloud.bigtable.util
 
RowKeyUtil() - Constructor for class com.google.cloud.bigtable.util.RowKeyUtil
 
RowKeyWrapper - Class in com.google.cloud.bigtable.util
For internal use only - public for technical reasons.
RowKeyWrapper(ByteString) - Constructor for class com.google.cloud.bigtable.util.RowKeyWrapper
 
RowMerger - Class in com.google.cloud.bigtable.grpc.scanner
Builds a complete FlatRow from ReadRowsResponse objects.
RowMerger(StreamObserver<FlatRow>) - Constructor for class com.google.cloud.bigtable.grpc.scanner.RowMerger
Constructor for RowMerger.
RowResultScanner<T> - Class in com.google.cloud.bigtable.grpc.scanner
A ResultScanner that wraps GCJ ServerStream.
RowResultScanner(ServerStream<T>, T[]) - Constructor for class com.google.cloud.bigtable.grpc.scanner.RowResultScanner
 
rpc - Variable in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation
 
rpcTimerContext - Variable in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation
 
run() - Method in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation
run() - Method in class com.google.cloud.bigtable.grpc.async.RetryingStreamOperation
run() - Method in class com.google.cloud.bigtable.grpc.io.Watchdog
 
run() - Method in class com.google.cloud.bigtable.grpc.scanner.RetryingReadRowsOperation
 

S

sampleRowKeys(String) - Method in interface com.google.cloud.bigtable.core.IBigtableDataClient
Sample row keys from a table.
sampleRowKeys(SampleRowKeysRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableDataClient
Sample row keys from a table.
sampleRowKeys(String) - Method in class com.google.cloud.bigtable.grpc.BigtableDataClientWrapper
Sample row keys from a table.
sampleRowKeys(String) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGCJClient
 
sampleRowKeys(SampleRowKeysRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGrpcClient
Sample row keys from a table.
sampleRowKeysAsync(String) - Method in interface com.google.cloud.bigtable.core.IBigtableDataClient
Sample row keys from a table, returning a Future that will complete when the sampling has completed.
sampleRowKeysAsync(SampleRowKeysRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableDataClient
Sample row keys from a table, returning a Future that will complete when the sampling has completed.
sampleRowKeysAsync(String) - Method in class com.google.cloud.bigtable.grpc.BigtableDataClientWrapper
Sample row keys from a table, returning a Future that will complete when the sampling has completed.
sampleRowKeysAsync(String) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGCJClient
 
sampleRowKeysAsync(SampleRowKeysRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGrpcClient
Sample row keys from a table, returning a Future that will complete when the sampling has completed.
ScanHandler - Interface in com.google.cloud.bigtable.grpc.scanner
An interface that handles timeout exception situations and request cancellations in scan situations.
ScanTimeoutException - Exception in com.google.cloud.bigtable.grpc.scanner
Deprecated.
ScanTimeoutException(String) - Constructor for exception com.google.cloud.bigtable.grpc.scanner.ScanTimeoutException
Deprecated.
Constructor for ScanTimeoutException.
sendUnsent() - Method in interface com.google.cloud.bigtable.core.IBulkMutation
Sends any outstanding entry, present in the current batch but doesn't wait for response.
sendUnsent() - Method in class com.google.cloud.bigtable.grpc.async.BulkMutation
 
sendUnsent() - Method in class com.google.cloud.bigtable.grpc.async.BulkMutationGCJClient
Sends any outstanding entry, present in the current batch but doesn't wait for response.
sendUnsent() - Method in class com.google.cloud.bigtable.grpc.async.BulkMutationWrapper
Sends any outstanding entry, present in the current batch but doesn't wait for response.
SERVICE_ACCOUNT_JSON_ENV_VARIABLE - Static variable in class com.google.cloud.bigtable.config.CredentialOptions
For internal use only - public for technical reasons.
set(RespT) - Method in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation.GrpcFuture
 
setAdminHost(String) - Method in class com.google.cloud.bigtable.config.BigtableOptions.Builder
 
setAllowRetriesWithoutTimestamp(boolean) - Method in class com.google.cloud.bigtable.config.RetryOptions.Builder
Perform retries even if a Put (or other Mutations) don't have a time stamp set and set the timestamp to the server time.
setAppProfileId(String) - Method in class com.google.cloud.bigtable.config.BigtableOptions.Builder
 
setAsyncMutatorWorkerCount(int) - Method in class com.google.cloud.bigtable.config.BulkOptions.Builder
 
setAutoflushMs(long) - Method in class com.google.cloud.bigtable.config.BulkOptions.Builder
 
setBackoffMultiplier(double) - Method in class com.google.cloud.bigtable.config.RetryOptions.Builder
Multiplier we will apply to backoff times between retries.
setBulkMaxRequestSize(long) - Method in class com.google.cloud.bigtable.config.BulkOptions.Builder
 
setBulkMaxRowKeyCount(int) - Method in class com.google.cloud.bigtable.config.BulkOptions.Builder
 
setBulkMutationRpcTargetMs(int) - Method in class com.google.cloud.bigtable.config.BulkOptions.Builder
Deprecated.
This will be removed in the future
setBulkOptions(BulkOptions) - Method in class com.google.cloud.bigtable.config.BigtableOptions.Builder
 
setCachedCredentails(Credentials) - Method in class com.google.cloud.bigtable.config.CredentialOptions.JsonCredentialsOptions
 
setCallOptionsConfig(CallOptionsConfig) - Method in class com.google.cloud.bigtable.config.BigtableOptions.Builder
 
setCallOptionsFactory(CallOptionsFactory) - Method in interface com.google.cloud.bigtable.grpc.BigtableDataClient
Sets a CallOptionsFactory which creates CallOptions
setCallOptionsFactory(CallOptionsFactory) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGrpcClient
Sets a CallOptionsFactory which creates CallOptions
setChannelConfigurator(BigtableOptions.ChannelConfigurator) - Method in class com.google.cloud.bigtable.config.BigtableOptions.Builder
For internal use only - public for technical reasons.
setClusterSize(String, String, int) - Method in class com.google.cloud.bigtable.grpc.BigtableClusterUtilities
Sets a cluster size to a specific size.
setClusterSize(int) - Method in class com.google.cloud.bigtable.grpc.BigtableClusterUtilities
Sets a cluster size to a specific size in an instance with a single cluster
setCredentialOptions(CredentialOptions) - Method in class com.google.cloud.bigtable.config.BigtableOptions.Builder
 
setCurrentInFlightMaxRpcs(int) - Method in class com.google.cloud.bigtable.grpc.async.ResourceLimiter
Setter for the field currentInFlightMaxRpcs.
setDataChannelCount(int) - Method in class com.google.cloud.bigtable.config.BigtableOptions.Builder
 
setDataHost(String) - Method in class com.google.cloud.bigtable.config.BigtableOptions.Builder
 
setEnableRetries(boolean) - Method in class com.google.cloud.bigtable.config.RetryOptions.Builder
Enable or disable retries.
setException(Throwable) - Method in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation.GrpcFuture
 
setException(Exception) - Method in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation
 
setException(Exception) - Method in class com.google.cloud.bigtable.grpc.scanner.RetryingReadRowsOperation
setHttpTransportFactory(HttpTransportFactory) - Static method in class com.google.cloud.bigtable.config.CredentialFactory
Allow for an override of the credentials HttpTransportFactory.
setIamPolicy(SetIamPolicyRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableInstanceClient
Set an IAM policy.
setIamPolicy(SetIamPolicyRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableInstanceGrpcClient
Set an IAM policy.
setIamPolicy(SetIamPolicyRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableTableAdminClient
Set an IAM policy.
setIamPolicy(SetIamPolicyRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGrpcClient
Set an IAM policy.
setInitialBackoffMillis(int) - Method in class com.google.cloud.bigtable.config.RetryOptions.Builder
The amount of time in milliseconds we will wait for our first error retry.
setInstanceId(String) - Method in class com.google.cloud.bigtable.config.BigtableOptions.Builder
 
setLevelToLog(BigtableClientMetrics.MetricLevel) - Static method in class com.google.cloud.bigtable.metrics.BigtableClientMetrics
Set a level at which to log.
setLongRpcTimeoutMs(int) - Method in class com.google.cloud.bigtable.config.CallOptionsConfig.Builder
setMaxElapsedBackoffMillis(int) - Method in class com.google.cloud.bigtable.config.RetryOptions.Builder
Maximum amount of time we will retry an operation that is failing.
setMaxInflightRpcs(int) - Method in class com.google.cloud.bigtable.config.BulkOptions.Builder
 
setMaxMemory(long) - Method in class com.google.cloud.bigtable.config.BulkOptions.Builder
 
setMaxScanTimeoutRetries(int) - Method in class com.google.cloud.bigtable.config.RetryOptions.Builder
Set the maximum number of times to retry after a scan timeout.
setMessageCompression(boolean) - Method in class com.google.cloud.bigtable.grpc.async.CallController
 
setMetricRegistry(MetricRegistry) - Static method in class com.google.cloud.bigtable.metrics.BigtableClientMetrics
Sets a MetricRegistry to be used in all Bigtable connection created after the call.
setMutateRpcTimeoutMs(int) - Method in class com.google.cloud.bigtable.config.CallOptionsConfig.Builder
The amount of time in milliseconds to wait before issuing a client side timeout for row mutation RPCs.
setOnReadyHandler(Runnable) - Method in class com.google.cloud.bigtable.grpc.async.CallController
 
setPort(int) - Method in class com.google.cloud.bigtable.config.BigtableOptions.Builder
 
setProjectId(String) - Method in class com.google.cloud.bigtable.config.BigtableOptions.Builder
 
setReadPartialRowTimeoutMillis(int) - Method in class com.google.cloud.bigtable.config.RetryOptions.Builder
Set the timeout in milliseconds for reading individual ReadRowsResponse messages from a stream.
setReadRowsRpcTimeoutMs(int) - Method in class com.google.cloud.bigtable.config.CallOptionsConfig.Builder
The amount of time in millisecond to wait before issuing a client side timeout for readRows streaming RPCs.
setResultObserver(StreamObserver<ReadRowsResponse>) - Method in class com.google.cloud.bigtable.grpc.scanner.RetryingReadRowsOperation
 
setRetryOnDeadlineExceeded(boolean) - Method in class com.google.cloud.bigtable.config.RetryOptions.Builder
Enable or disable retry on deadline exceeded.
setRetryOptions(RetryOptions) - Method in class com.google.cloud.bigtable.config.BigtableOptions.Builder
 
setShortRpcTimeoutMs(int) - Method in class com.google.cloud.bigtable.config.CallOptionsConfig.Builder
The amount of milliseconds to wait before issuing a client side timeout for short RPCs.
setStreamingBufferSize(int) - Method in class com.google.cloud.bigtable.config.RetryOptions.Builder
Set the maximum number of messages to buffer when scanning.
setTimeoutMs(int) - Method in class com.google.cloud.bigtable.config.CallOptionsConfig.Builder
Deprecated.
setupTracingConfig() - Static method in class com.google.cloud.bigtable.util.TracingUtilities
This is a one time setup for grpcz pages.
setUseBatch(boolean) - Method in class com.google.cloud.bigtable.config.BigtableOptions.Builder
 
setUseBulkApi(boolean) - Method in class com.google.cloud.bigtable.config.BulkOptions.Builder
 
setUseCachedDataPool(boolean) - Method in class com.google.cloud.bigtable.config.BigtableOptions.Builder
This enables an experimental BigtableSession feature that caches datapools for cases where there are many HBase Connections / BigtableSessions opened.
setUseGCJClient(boolean) - Method in class com.google.cloud.bigtable.config.BigtableOptions.Builder
 
setUsePlaintextNegotiation(boolean) - Method in class com.google.cloud.bigtable.config.BigtableOptions.Builder
 
setUserAgent(String) - Method in class com.google.cloud.bigtable.config.BigtableOptions.Builder
 
setUseTimeout(boolean) - Method in class com.google.cloud.bigtable.config.CallOptionsConfig.Builder
If true, turn on timeouts for unary RPCS like mutations, and single row readRows.
SHORT_TIMEOUT_MS_DEFAULT - Static variable in class com.google.cloud.bigtable.config.CallOptionsConfig
The default duration to wait before timing out RPCs.
shutdown() - Method in class com.google.cloud.bigtable.grpc.io.ChannelPool
shutdownNow() - Method in class com.google.cloud.bigtable.grpc.io.ChannelPool
size() - Method in class com.google.cloud.bigtable.grpc.io.ChannelPool
size.
snapshotTableAsync(SnapshotTableRequest) - Method in interface com.google.cloud.bigtable.core.IBigtableTableAdminClient
Deprecated.
this will be removed in a future release - please use backups API instead
snapshotTableAsync(SnapshotTableRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableTableAdminClient
Deprecated.
Snapshots will be removed in the future
snapshotTableAsync(SnapshotTableRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminClientWrapper
 
snapshotTableAsync(SnapshotTableRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGCJClient
Creates a new snapshot from a table in a specific cluster.
snapshotTableAsync(SnapshotTableRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGrpcClient
start(REQUEST, ClientCall.Listener<RESPONSE>, Metadata, ClientCall<REQUEST, RESPONSE>) - Method in interface com.google.cloud.bigtable.grpc.async.BigtableAsyncRpc
Starts a ClientCall.
start(ScheduledExecutorService) - Method in class com.google.cloud.bigtable.grpc.io.Watchdog
 
startCell(String, ByteString, long, List<String>, long) - Method in class com.google.cloud.bigtable.grpc.scanner.FlatRowAdapter.FlatRowBuilder
startRow(ByteString) - Method in class com.google.cloud.bigtable.grpc.scanner.FlatRowAdapter.FlatRowBuilder
STATS - Static variable in class com.google.cloud.bigtable.grpc.io.ChannelPool
 
stop() - Method in class com.google.cloud.bigtable.grpc.io.Watchdog
 
StreamObserverAdapter<T> - Class in com.google.cloud.bigtable.grpc.scanner
Deprecated.
StreamObserverAdapter(ClientCall<?, T>, StreamObserver<T>) - Constructor for class com.google.cloud.bigtable.grpc.scanner.StreamObserverAdapter
Deprecated.
Constructor for StreamObserverAdapter.
StreamWaitTimeoutException(Watchdog.State, long) - Constructor for exception com.google.cloud.bigtable.grpc.io.Watchdog.StreamWaitTimeoutException
 

T

TABLE_SEPARATOR - Static variable in class com.google.cloud.bigtable.grpc.BigtableInstanceName
Constant TABLE_SEPARATOR="/tables/"
testIamPermissions(TestIamPermissionsRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableInstanceClient
Tests an IAM policy.
testIamPermissions(TestIamPermissionsRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableInstanceGrpcClient
Tests an IAM policy.
testIamPermissions(TestIamPermissionsRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableTableAdminClient
Tests an IAM policy.
testIamPermissions(TestIamPermissionsRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGrpcClient
Tests an IAM policy.
ThreadUtil - Class in com.google.cloud.bigtable.util
Creates a ThreadFactory that's safe to use in App Engine.
ThreadUtil() - Constructor for class com.google.cloud.bigtable.util.ThreadUtil
 
throttle(int) - Method in class com.google.cloud.bigtable.grpc.async.ResourceLimiter
Enable an experimental feature that will throttle requests made from BulkMutation.
ThrottlingClientInterceptor - Class in com.google.cloud.bigtable.grpc.async
Throttles requests based on ResourceLimiter
ThrottlingClientInterceptor(ResourceLimiter) - Constructor for class com.google.cloud.bigtable.grpc.async.ThrottlingClientInterceptor
 
time() - Method in interface com.google.cloud.bigtable.metrics.Timer
Returns a new Timer.Context.
timeOperation() - Method in class com.google.cloud.bigtable.grpc.async.BigtableAsyncRpc.RpcMetrics
 
timer(BigtableClientMetrics.MetricLevel, String) - Static method in class com.google.cloud.bigtable.metrics.BigtableClientMetrics
Creates a named Timer.
timer(String) - Method in class com.google.cloud.bigtable.metrics.DropwizardMetricRegistry
Creates a named Timer that wraps a Dropwizard Metrics Timer.
timer(String) - Method in interface com.google.cloud.bigtable.metrics.MetricRegistry
Creates a named Timer.
Timer - Interface in com.google.cloud.bigtable.metrics
A timer metric which aggregates timing durations and provides duration statistics, plus throughput statistics.
Timer.Context - Interface in com.google.cloud.bigtable.metrics
A timing context.
timeRpc() - Method in class com.google.cloud.bigtable.grpc.async.BigtableAsyncRpc.RpcMetrics
 
toBackupName(String) - Method in class com.google.cloud.bigtable.grpc.BigtableClusterName
Create a fully qualified backup name based on the the clusterName and the backupId.
toBuilder() - Method in class com.google.cloud.bigtable.config.BigtableOptions
toBuilder.
toBuilder() - Method in class com.google.cloud.bigtable.config.BulkOptions
toBuilder.
toBuilder() - Method in class com.google.cloud.bigtable.config.CallOptionsConfig
toBuilder.
toBuilder() - Method in class com.google.cloud.bigtable.config.RetryOptions
toBuilder.
toClusterName(String) - Method in class com.google.cloud.bigtable.grpc.BigtableInstanceName
 
toRows(Iterable<ReadRowsResponse>) - Static method in class com.google.cloud.bigtable.grpc.scanner.RowMerger
toRows.
toSnapshotName(String) - Method in class com.google.cloud.bigtable.grpc.BigtableClusterName
Deprecated.
this will be removed in a future release - please use backups API instead
toString() - Method in class com.google.cloud.bigtable.config.BigtableOptions
toString() - Method in class com.google.cloud.bigtable.config.BulkOptions
toString() - Method in class com.google.cloud.bigtable.config.CallOptionsConfig
toString() - Method in class com.google.cloud.bigtable.config.RetryOptions
toString() - Method in class com.google.cloud.bigtable.grpc.BigtableClusterName
 
toString() - Method in class com.google.cloud.bigtable.grpc.BigtableInstanceName
toString() - Method in class com.google.cloud.bigtable.grpc.BigtableSnapshotName
Deprecated.
Returns the fully qualified Snapshot name.
toString() - Method in class com.google.cloud.bigtable.grpc.BigtableTableName
toString() - Method in class com.google.cloud.bigtable.grpc.io.HeaderInterceptor
 
toString() - Method in class com.google.cloud.bigtable.grpc.scanner.FlatRow.Cell
 
toString() - Method in class com.google.cloud.bigtable.grpc.scanner.FlatRow
 
toTableId(String) - Method in class com.google.cloud.bigtable.grpc.BigtableInstanceName
Transforms a tableName within this instance of the form projects/(projectId)/instances/(instanceId)/tables/(tableId) to (tableId).
toTableName(String) - Method in class com.google.cloud.bigtable.grpc.BigtableInstanceName
toTableName.
toTableNameStr(String) - Method in class com.google.cloud.bigtable.grpc.BigtableInstanceName
toTableNameStr.
trace(String, Object...) - Method in class com.google.cloud.bigtable.config.Logger
trace
TracingUtilities - Class in com.google.cloud.bigtable.util
These utilities are to be used in conjunction with the opencensus-contrib-zpages artifact to display a consistent set of Cloud Bigtable RPC methods.
transformAndAdapt(ListenableFuture<F>, Function<F, T>) - Static method in class com.google.cloud.bigtable.util.ApiFutureUtil
 

U

UNARY_DEADLINE_MINUTES - Static variable in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation
 
update(long, TimeUnit) - Method in interface com.google.cloud.bigtable.metrics.Timer
Adds a recorded duration.
updateAppProfile(UpdateAppProfileRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableInstanceClient
/** Update an application profile.
updateAppProfile(UpdateAppProfileRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableInstanceGrpcClient
/** Update an application profile.
updateBackupAsync(UpdateBackupRequest) - Method in interface com.google.cloud.bigtable.core.IBigtableTableAdminClient
Update the specified backup.
updateBackupAsync(UpdateBackupRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableTableAdminClient
Updates the specified backup.
updateBackupAsync(UpdateBackupRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminClientWrapper
 
updateBackupAsync(UpdateBackupRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGCJClient
 
updateBackupAsync(UpdateBackupRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGrpcClient
 
updateCluster(Cluster) - Method in interface com.google.cloud.bigtable.grpc.BigtableInstanceClient
Updates a cluster within an instance.
updateCluster(Cluster) - Method in class com.google.cloud.bigtable.grpc.BigtableInstanceGrpcClient
Updates a cluster within an instance.
updateHeaders(Metadata) - Method in class com.google.cloud.bigtable.grpc.io.HeaderInterceptor
 
updateInstance(Instance) - Method in interface com.google.cloud.bigtable.grpc.BigtableInstanceClient
updateInstance(Instance) - Method in class com.google.cloud.bigtable.grpc.BigtableInstanceGrpcClient
USE_TIMEOUT_DEFAULT - Static variable in class com.google.cloud.bigtable.config.CallOptionsConfig
Constant USE_TIMEOUT_DEFAULT=false
useBatch() - Method in class com.google.cloud.bigtable.config.BigtableOptions
 
useBulkApi() - Method in class com.google.cloud.bigtable.config.BulkOptions
useBulkApi.
useCachedChannel() - Method in class com.google.cloud.bigtable.config.BigtableOptions
Experimental feature to allow situations with multiple connections to optimize their startup time.
useGCJClient() - Method in class com.google.cloud.bigtable.config.BigtableOptions
useGCJClient
usePlaintextNegotiation() - Method in class com.google.cloud.bigtable.config.BigtableOptions
usePlaintextNegotiation.
UserSuppliedCredentialOptions(Credentials) - Constructor for class com.google.cloud.bigtable.config.CredentialOptions.UserSuppliedCredentialOptions
 

V

valueOf(String) - Static method in enum com.google.cloud.bigtable.config.CredentialOptions.CredentialType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.cloud.bigtable.grpc.async.MutateRowsRequestManager.ProcessingStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.cloud.bigtable.grpc.io.Watchdog.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.cloud.bigtable.metrics.BigtableClientMetrics.MetricLevel
Returns the enum constant of this type with the specified name.
values() - Static method in enum com.google.cloud.bigtable.config.CredentialOptions.CredentialType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.google.cloud.bigtable.grpc.async.MutateRowsRequestManager.ProcessingStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.google.cloud.bigtable.grpc.io.Watchdog.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.google.cloud.bigtable.metrics.BigtableClientMetrics.MetricLevel
Returns an array containing the constants of this enum type, in the order they are declared.

W

waitForOperation(String, int) - Method in class com.google.cloud.bigtable.grpc.BigtableClusterUtilities
Waits for an operation like cluster resizing to complete.
waitForOperation(Operation) - Method in interface com.google.cloud.bigtable.grpc.BigtableInstanceClient
Waits for the long running operation to complete by polling with exponential backoff.
waitForOperation(Operation, long, TimeUnit) - Method in interface com.google.cloud.bigtable.grpc.BigtableInstanceClient
Waits for the long running operation to complete by polling with exponential backoff.
waitForOperation(Operation) - Method in class com.google.cloud.bigtable.grpc.BigtableInstanceGrpcClient
Waits for the long running operation to complete by polling with exponential backoff.
waitForOperation(Operation, long, TimeUnit) - Method in class com.google.cloud.bigtable.grpc.BigtableInstanceGrpcClient
Waits for the long running operation to complete by polling with exponential backoff.
waitForOperation(Operation) - Method in interface com.google.cloud.bigtable.grpc.BigtableTableAdminClient
Waits for the long running operation to complete by polling with exponential backoff.
waitForOperation(Operation, long, TimeUnit) - Method in interface com.google.cloud.bigtable.grpc.BigtableTableAdminClient
Waits for the long running operation to complete by polling with exponential backoff.
waitForOperation(Operation) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGrpcClient
Waits for the long running operation to complete by polling with exponential backoff.
waitForOperation(Operation, long, TimeUnit) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGrpcClient
Waits for the long running operation to complete by polling with exponential backoff.
waitForOperation(Operation) - Method in class com.google.cloud.bigtable.util.OperationUtil
 
waitForOperation(Operation, long, TimeUnit) - Method in class com.google.cloud.bigtable.util.OperationUtil
 
waitForReplication(BigtableTableName, long) - Method in interface com.google.cloud.bigtable.grpc.BigtableTableAdminClient
Blocks until replication has caught up to the point this method was called or timeout is reached.
waitForReplication(BigtableTableName, long) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGrpcClient
Blocks until replication has caught up to the point this method was called or timeout is reached.
warn(String, Object...) - Method in class com.google.cloud.bigtable.config.Logger
warn
warn(String, Throwable, Object...) - Method in class com.google.cloud.bigtable.config.Logger
warn
watch(ClientCall<ReqT, RespT>) - Method in class com.google.cloud.bigtable.grpc.io.Watchdog
 
Watchdog - Class in com.google.cloud.bigtable.grpc.io
Prevents the streams from hanging indefinitely.
Watchdog(Clock, long) - Constructor for class com.google.cloud.bigtable.grpc.io.Watchdog
 
Watchdog(Clock, long, long) - Constructor for class com.google.cloud.bigtable.grpc.io.Watchdog
 
Watchdog.State - Enum in com.google.cloud.bigtable.grpc.io
 
Watchdog.StreamWaitTimeoutException - Exception in com.google.cloud.bigtable.grpc.io
Marker exception to replace cancelled status with aborted to allow retries.
WatchdogInterceptor - Class in com.google.cloud.bigtable.grpc.io
Internal implementation detail to prevent RPC from hanging.
WatchdogInterceptor(Set<MethodDescriptor<?, ?>>, Watchdog) - Constructor for class com.google.cloud.bigtable.grpc.io.WatchdogInterceptor
 
withFamily(String) - Method in class com.google.cloud.bigtable.grpc.scanner.FlatRow.Cell.Builder
 
withLabels(List<String>) - Method in class com.google.cloud.bigtable.grpc.scanner.FlatRow.Cell.Builder
 
withQualifier(ByteString) - Method in class com.google.cloud.bigtable.grpc.scanner.FlatRow.Cell.Builder
 
withRowKey(ByteString) - Method in class com.google.cloud.bigtable.grpc.scanner.FlatRow.Builder
 
withTimestamp(long) - Method in class com.google.cloud.bigtable.grpc.scanner.FlatRow.Cell.Builder
 
withValue(ByteString) - Method in class com.google.cloud.bigtable.grpc.scanner.FlatRow.Cell.Builder
 
A B C D E F G H I J L M N O P R S T U V W 
Skip navigation links