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

A

AbstractRetryingRpcListener<RequestT,ResponseT,ResultT> - Class in com.google.cloud.bigtable.grpc.async
A AsyncFunction that retries a BigtableAsyncRpc request.
AbstractRetryingRpcListener(RetryOptions, RequestT, BigtableAsyncRpc<RequestT, ResponseT>, CallOptions, ScheduledExecutorService, Metadata) - Constructor for class com.google.cloud.bigtable.grpc.async.AbstractRetryingRpcListener
Constructor for AbstractRetryingRpcListener.
AbstractRetryingRpcListener.GrpcFuture<RespT> - Class in com.google.cloud.bigtable.grpc.async
 
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(ReadRowsRequest) - Method in class com.google.cloud.bigtable.grpc.async.BulkRead
Adds the key in the request to a batch read.
addCallback(ListenableFuture<T>, long) - Method in class com.google.cloud.bigtable.grpc.async.RpcThrottler
Add a callback to a Future representing an RPC call with the given operation id that will clean upon completion and reclaim any utilized resources.
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
 
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?
ARE_RETRYABLE_MUTATIONS - Static variable in class com.google.cloud.bigtable.grpc.BigtableDataGrpcClient
Constant ARE_RETRYABLE_MUTATIONS
AsyncExecutor - Class in com.google.cloud.bigtable.grpc.async
This class provides management of asynchronous Bigtable RPCs.
AsyncExecutor(BigtableDataClient, RpcThrottler) - Constructor for class com.google.cloud.bigtable.grpc.async.AsyncExecutor
Constructor for AsyncExecutor.
AsyncExecutor.AsyncCall<RequestT,ResponseT> - Interface in com.google.cloud.bigtable.grpc.async
 
asyncRefresh() - Method in class com.google.cloud.bigtable.grpc.io.RefreshingOAuth2CredentialsInterceptor
Refreshes the OAuth2 token asynchronously.
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.
awaitCompletion() - Method in class com.google.cloud.bigtable.grpc.async.RpcThrottler
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.
BIGTABLE_ASYNC_MUTATOR_COUNT_DEFAULT - Static variable in class com.google.cloud.bigtable.config.BulkOptions
Constant BIGTABLE_ASYNC_MUTATOR_COUNT_DEFAULT=2
BIGTABLE_BATCH_DATA_HOST_DEFAULT - Static variable in class com.google.cloud.bigtable.config.BigtableOptions
Constant BIGTABLE_BATCH_DATA_HOST_DEFAULT="bigtable.googleapis.com"
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_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 mutation requests to bundle in a single bulk mutation RPC before sending it to the server and starting the next bulk call.
BIGTABLE_DATA_CHANNEL_COUNT_DEFAULT - Static variable in class com.google.cloud.bigtable.config.BigtableOptions
Constant BIGTABLE_DATA_CHANNEL_COUNT_DEFAULT=getDefaultDataChannelCount()
BIGTABLE_DATA_HOST_DEFAULT - Static variable in class com.google.cloud.bigtable.config.BigtableOptions
Constant BIGTABLE_DATA_HOST_DEFAULT="bigtable.googleapis.com"
BIGTABLE_EMULATOR_HOST_ENV_VAR - Static variable in class com.google.cloud.bigtable.config.BigtableOptions
Constant BIGTABLE_EMULATOR_HOST_ENV_VAR="bigtableadmin.googleapis.com"
BIGTABLE_INSTANCE_ADMIN_HOST_DEFAULT - Static variable in class com.google.cloud.bigtable.config.BigtableOptions
Constant BIGTABLE_INSTANCE_ADMIN_HOST_DEFAULT="bigtableadmin.googleapis.com"
BIGTABLE_MAX_INFLIGHT_RPCS_PER_CHANNEL_DEFAULT - Static variable in class com.google.cloud.bigtable.config.BulkOptions
Constant BIGTABLE_MAX_INFLIGHT_RPCS_PER_CHANNEL_DEFAULT=50
BIGTABLE_MAX_MEMORY_DEFAULT - Static variable in class com.google.cloud.bigtable.config.BulkOptions
Constant BIGTABLE_MAX_MEMORY_DEFAULT=(long) Math.min(1 << 30, (Runtime.getRuntime().maxMemory() * 0.1d))
BIGTABLE_PORT_DEFAULT - Static variable in class com.google.cloud.bigtable.config.BigtableOptions
Constant BIGTABLE_PORT_DEFAULT=443
BIGTABLE_TABLE_ADMIN_HOST_DEFAULT - Static variable in class com.google.cloud.bigtable.config.BigtableOptions
Constant BIGTABLE_TABLE_ADMIN_HOST_DEFAULT="bigtableadmin.googleapis.com"
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
 
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.
BigtableDataGrpcClient - Class in com.google.cloud.bigtable.grpc
A gRPC client to access the v2 Bigtable data service.
BigtableDataGrpcClient(ChannelPool, 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
Constructor for BigtableInstanceName.
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.
BigtableResultScannerFactory<ResponseT> - Interface in com.google.cloud.bigtable.grpc.scanner
A factory for creating ResultScanners that can be used to scan over Rows for a given ReadRowsRequest.
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
Constructor for BigtableRetriesExhaustedException.
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
This class encapsulates a Snapshot name of the form projects/(projectId)/instances/(instanceId)/clusters/(clusterId)
BigtableSnapshotName(String) - Constructor for class com.google.cloud.bigtable.grpc.BigtableSnapshotName
 
BigtableTableAdminClient - Interface in com.google.cloud.bigtable.grpc
A client for the Cloud Bigtable Table Admin API.
BigtableTableAdminGrpcClient - Class in com.google.cloud.bigtable.grpc
A gRPC client for accessing the Bigtable Table Admin API.
BigtableTableAdminGrpcClient(Channel) - 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
 
BigtableVersionInfo - Class in com.google.cloud.bigtable.config
 
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() - Constructor for class com.google.cloud.bigtable.config.BigtableOptions.Builder
 
Builder() - Constructor for class com.google.cloud.bigtable.config.BulkOptions.Builder
 
Builder() - Constructor for class com.google.cloud.bigtable.config.CallOptionsConfig.Builder
 
Builder() - Constructor for class com.google.cloud.bigtable.config.RetryOptions.Builder
 
Builder(RetryOptions) - Constructor for class com.google.cloud.bigtable.config.RetryOptions.Builder
 
Builder() - Constructor for class com.google.cloud.bigtable.grpc.scanner.FlatRow.Cell.Builder
 
BulkMutation - Class in com.google.cloud.bigtable.grpc.async
This class combines a collection of MutateRowRequests into a single MutateRowsRequest.
BulkMutation(BigtableTableName, AsyncExecutor, RetryOptions, ScheduledExecutorService, int, long) - Constructor for class com.google.cloud.bigtable.grpc.async.BulkMutation
Constructor for BulkMutation.
BulkMutation(BigtableTableName, AsyncExecutor, RetryOptions, ScheduledExecutorService, int, long, long) - Constructor for class com.google.cloud.bigtable.grpc.async.BulkMutation
Constructor for BulkMutation.
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(BigtableDataClient, 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
 
ByteStringer - Class in com.google.cloud.bigtable.util
Wrapper around ZeroCopyByteStringUtil for cases where it's not available.

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 - Variable in class com.google.cloud.bigtable.grpc.async.AbstractRetryingRpcListener
 
call(BigtableDataClient, RequestT) - Method in interface com.google.cloud.bigtable.grpc.async.AsyncExecutor.AsyncCall
 
callLock - Variable in class com.google.cloud.bigtable.grpc.async.AbstractRetryingRpcListener
 
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
Constructor for CallOptionsConfig.
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
Always returns CallOptions.DEFAULT.
cancel() - Method in class com.google.cloud.bigtable.grpc.async.AbstractRetryingRpcListener
Cancels the RPC.
cancel(String) - Method in class com.google.cloud.bigtable.grpc.async.AbstractRetryingRpcListener
Cancels the RPC with a specific message.
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
 
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.
CHECK_AND_MUTATE_ASYNC - Static variable in class com.google.cloud.bigtable.grpc.async.AsyncExecutor
checkAndMutateRow(CheckAndMutateRowRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableDataClient
Mutate a row atomically dependent on a precondition.
checkAndMutateRow(CheckAndMutateRowRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGrpcClient
Mutate a row atomically dependent on a precondition.
checkAndMutateRowAsync(CheckAndMutateRowRequest, long) - Method in class com.google.cloud.bigtable.grpc.async.AsyncExecutor
checkAndMutateRowAsync(CheckAndMutateRowRequest) - Method in class com.google.cloud.bigtable.grpc.async.AsyncExecutor
checkAndMutateRowAsync(CheckAndMutateRowRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableDataClient
Mutate a row atomically dependent on a precondition.
checkAndMutateRowAsync(CheckAndMutateRowRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGrpcClient
Mutate a row atomically dependent on a precondition.
CLIENT_VERSION - Static variable in class com.google.cloud.bigtable.config.BigtableVersionInfo
 
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.BigtableSession
close() - Method in class com.google.cloud.bigtable.grpc.scanner.ResumingStreamingResultScanner
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.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.AbstractRetryingRpcListener
 
completionMarkerFound - Variable in class com.google.cloud.bigtable.grpc.scanner.ResponseQueueReader
 
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
 
convert(Row) - Static method in class com.google.cloud.bigtable.grpc.scanner.FlatRowConverter
 
CORE_UESR_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
 
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
 
createAsyncExecutor() - Method in class com.google.cloud.bigtable.grpc.BigtableSession
createAsyncExecutor.
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
 
createBackoff() - Method in class com.google.cloud.bigtable.config.RetryOptions
createBackoff.
createBackoffBuilder() - Method in class com.google.cloud.bigtable.config.RetryOptions
createBackoffBuilder.
createBulkMutation(BigtableTableName, AsyncExecutor) - Method in class com.google.cloud.bigtable.grpc.BigtableSession
createBulkMutation.
createBulkRead(BigtableTableName) - Method in class com.google.cloud.bigtable.grpc.BigtableSession
createBulkRead.
createChannelPool(String, int) - Method in class com.google.cloud.bigtable.grpc.BigtableSession
Create a new ChannelPool, with auth headers.
createChannelPool(String, BigtableOptions) - Static method in class com.google.cloud.bigtable.grpc.BigtableSession
Create a new ChannelPool, with auth headers.
createChannelPool(String, BigtableOptions, int) - Static method in class com.google.cloud.bigtable.grpc.BigtableSession
Create a new ChannelPool, with auth headers.
createCompletionFuture() - Method in class com.google.cloud.bigtable.grpc.async.AbstractRetryingRpcListener
 
createCompletionFuture() - Method in class com.google.cloud.bigtable.grpc.scanner.ReadRowsRetryListener
The stream observer handles responses.
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.
createManagedPool(String, int) - Method in class com.google.cloud.bigtable.grpc.BigtableSession
Create a new ChannelPool, with auth headers, that will be cleaned up when the connection closes.
createNettyChannel(String, BigtableOptions, ClientInterceptor...) - Static method in class com.google.cloud.bigtable.grpc.BigtableSession
createNettyChannel.
createRpcMetrics(MethodDescriptor<?, ?>) - Static method in class com.google.cloud.bigtable.grpc.async.BigtableAsyncRpc.RpcMetrics
 
createScanner(ReadRowsRequest) - Method in interface com.google.cloud.bigtable.grpc.scanner.BigtableResultScannerFactory
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.grpc.BigtableTableAdminClient
Creates a new table.
createTable(CreateTableRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGrpcClient
Creates a new table.
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.
currentBackoff - Variable in class com.google.cloud.bigtable.grpc.async.AbstractRetryingRpcListener
 

D

debug(String, 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: 2).
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
Constant DEFAULT_ENABLE_GRPC_RETRIES_SET
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
Constant DEFAULT_STREAMING_BUFFER_SIZE=60
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.
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.
deleteTable(DeleteTableRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableTableAdminClient
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.
dropRowRange(DropRowRangeRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableTableAdminClient
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.
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
 

E

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
extract(ByteString) - Static method in class com.google.cloud.bigtable.util.ByteStringer
 
extractIdentifier(Metadata) - Static method in class com.google.cloud.bigtable.grpc.io.ChannelPool
 

F

failedCount - Variable in class com.google.cloud.bigtable.grpc.async.AbstractRetryingRpcListener
 
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
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
 
FlatRow.Builder - Class in com.google.cloud.bigtable.grpc.scanner
 
FlatRow.Cell - Class in com.google.cloud.bigtable.grpc.scanner
 
FlatRow.Cell.Builder - Class in com.google.cloud.bigtable.grpc.scanner
 
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 class com.google.cloud.bigtable.grpc.async.AsyncExecutor
Waits until all operations managed by the RpcThrottler complete.
flush() - Method in class com.google.cloud.bigtable.grpc.async.BulkMutation
Send any outstanding MutateRowRequests.
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

get(ByteString) - Static method in class com.google.cloud.bigtable.util.ZeroCopyByteStringUtil
Extracts the byte array from the given ByteString without copy.
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.
getAsyncMutatorCount() - Method in class com.google.cloud.bigtable.config.BulkOptions
Getter for the field asyncMutatorCount.
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.
getBatchThreadPool() - Method in class com.google.cloud.bigtable.grpc.BigtableSessionSharedThreadPools
Getter for the field batchThreadPool.
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.
getBulkOptions() - Method in class com.google.cloud.bigtable.config.BigtableOptions
Getter for the field bulkOptions.
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
 
getChannelCount() - Method in class com.google.cloud.bigtable.config.BigtableOptions
The number of data channels to create.
getClient() - Method in class com.google.cloud.bigtable.grpc.async.AsyncExecutor
Getter for the field client.
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.config.BigtableOptions
Getter for the field clusterId.
getClusterId() - Method in class com.google.cloud.bigtable.grpc.BigtableClusterName
 
getClusterId() - Method in class com.google.cloud.bigtable.grpc.BigtableSnapshotName
 
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.
getCompletionFuture() - Method in class com.google.cloud.bigtable.grpc.async.AbstractRetryingRpcListener
Getter for the field completionFuture.
getCredential() - Method in class com.google.cloud.bigtable.config.CredentialOptions.UserSuppliedCredentialOptions
 
getCredentialFromMetadataServiceAccount() - Static method in class com.google.cloud.bigtable.config.CredentialFactory
Initializes OAuth2 credential using preconfigured ServiceAccount settings on the local Google Compute Engine VM.
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.
getDataChannelCount() - Method in class com.google.cloud.bigtable.config.BigtableOptions.Builder
 
getDataClient() - Method in class com.google.cloud.bigtable.grpc.BigtableSession
Getter for the field dataClient.
getDataHost() - Method in class com.google.cloud.bigtable.config.BigtableOptions
Getter for the field dataHost.
getEnvJsonFile() - Static method in class com.google.cloud.bigtable.config.CredentialOptions
Get a configured json credentials file from the GOOGLE_APPLICATION_CREDENTIALS environment variable.
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
 
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() - 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.
getInstanceAdminHost() - Method in class com.google.cloud.bigtable.config.BigtableOptions
Getter for the field instanceAdminHost.
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
 
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() - 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
 
getLongRpcTimeoutMs() - Method in class com.google.cloud.bigtable.config.CallOptionsConfig
Getter for the field longRpcTimeoutMs.
getMaxElaspedBackoffMillis() - 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.AsyncExecutor
getMaxHeapSize.
getMaxHeapSize() - Method in class com.google.cloud.bigtable.grpc.async.ResourceLimiter
Getter for the field maxHeapSize.
getMaxHeapSize() - Method in class com.google.cloud.bigtable.grpc.async.RpcThrottler
getMaxHeapSize.
getMaxInflightRpcs() - Method in class com.google.cloud.bigtable.config.BulkOptions
Getter for the field maxInflightRpcs.
getMaxInFlightRpcs() - Method in class com.google.cloud.bigtable.grpc.async.ResourceLimiter
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
 
getNext() - Method in class com.google.cloud.bigtable.grpc.scanner.ResponseQueueReader
getNext.
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.
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
 
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.
getRegistry() - Method in class com.google.cloud.bigtable.metrics.DropwizardMetricRegistry
 
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.AbstractRetryingRpcListener
 
getRetryRequest() - Method in class com.google.cloud.bigtable.grpc.scanner.ReadRowsRetryListener
Updates the original request via ReadRowsRequestManager.buildUpdatedRequest().
getRetryState(BackOff) - Method in class com.google.cloud.bigtable.grpc.io.RefreshingOAuth2CredentialsInterceptor
Sleep and/or determine if the backoff has timed out.
getRowKey() - Method in class com.google.cloud.bigtable.grpc.scanner.FlatRow.Builder
 
getRowKey() - Method in class com.google.cloud.bigtable.grpc.scanner.FlatRow
 
getRowMerger() - Method in class com.google.cloud.bigtable.grpc.scanner.ReadRowsRetryListener
 
getRpcMetrics() - Method in interface com.google.cloud.bigtable.grpc.async.BigtableAsyncRpc
 
getRpcThrottler() - Method in class com.google.cloud.bigtable.grpc.async.AsyncExecutor
Getter for the field rpcThrottler.
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
 
getSnapshotId() - Method in class com.google.cloud.bigtable.grpc.BigtableSnapshotName
 
getSnapshotName() - Method in class com.google.cloud.bigtable.grpc.BigtableSnapshotName
 
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
The maximum number of messages to buffer when scanning.
getStreamingFuture(ReqT, BigtableAsyncRpc<ReqT, RespT>, String) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGrpcClient
getStreamingFuture.
getTable(GetTableRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableTableAdminClient
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.
getTableAdminHost() - Method in class com.google.cloud.bigtable.config.BigtableOptions
Getter for the field tableAdminHost.
getTableId() - Method in class com.google.cloud.bigtable.grpc.BigtableTableName
 
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
 
getZoneId() - Method in class com.google.cloud.bigtable.config.BigtableOptions
Getter for the field zoneId.
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.AbstractRetryingRpcListener.GrpcFuture
 

H

handleTimeout(ScanTimeoutException) - Method in class com.google.cloud.bigtable.grpc.scanner.ReadRowsRetryListener
This gets called by ResumingStreamingResultScanner when a queue is empty via ResponseQueueReader.getNext().
handleTimeout(ScanTimeoutException) - Method in interface com.google.cloud.bigtable.grpc.scanner.ScanHandler
Handle exceptions found in ResponseQueueReader.getNext().
hasInflightRequests() - Method in class com.google.cloud.bigtable.grpc.async.AsyncExecutor
hasInflightRequests.
hasInflightRequests() - Method in class com.google.cloud.bigtable.grpc.async.ResourceLimiter
hasInflightRequests.
hasInflightRequests() - Method in class com.google.cloud.bigtable.grpc.async.RpcThrottler
hasInflightRequests.
hasStatusBeenRecieved() - Method in class com.google.cloud.bigtable.grpc.scanner.StreamObserverAdapter
 

I

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
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.io.GoogleCloudResourcePrefixInterceptor
interceptCall(MethodDescriptor<ReqT, RespT>, CallOptions, Channel) - Method in class com.google.cloud.bigtable.grpc.io.RefreshingOAuth2CredentialsInterceptor
interruptTask() - Method in class com.google.cloud.bigtable.grpc.async.AbstractRetryingRpcListener.GrpcFuture
 
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_CHECK_AND_MUTATE - Static variable in class com.google.cloud.bigtable.grpc.BigtableDataGrpcClient
Constant IS_RETRYABLE_CHECK_AND_MUTATE
IS_RETRYABLE_MUTATION - Static variable in class com.google.cloud.bigtable.grpc.BigtableDataGrpcClient
Constant IS_RETRYABLE_MUTATION
isAlpnProviderEnabled() - Static method in class com.google.cloud.bigtable.grpc.BigtableSession
isAlpnProviderEnabled.
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.
isRequestRetryable() - Method in class com.google.cloud.bigtable.grpc.async.AbstractRetryingRpcListener
 
isRequestRetryable() - Method in class com.google.cloud.bigtable.grpc.scanner.ReadRowsRetryListener
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?
isShutdown() - Method in class com.google.cloud.bigtable.grpc.io.ChannelPool
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.
JsonCredentialsOptions(InputStream) - Constructor for class com.google.cloud.bigtable.config.CredentialOptions.JsonCredentialsOptions
 

L

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.
listTables(ListTablesRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableTableAdminClient
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.
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.AbstractRetryingRpcListener
Constant LOG
LOG - Static variable in class com.google.cloud.bigtable.grpc.async.AsyncExecutor
Constant LOG
LOG - Static variable in class com.google.cloud.bigtable.grpc.async.BulkMutation
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.async.RpcThrottler
Constant LOG
LOG - Static variable in class com.google.cloud.bigtable.grpc.io.ChannelPool
Constant LOG
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_RPC_WAIT_TIME - Static variable in class com.google.cloud.bigtable.grpc.async.BulkMutation
 
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.
MUTATE_ROW_ASYNC - Static variable in class com.google.cloud.bigtable.grpc.async.AsyncExecutor
MUTATE_ROWS_ASYNC - Static variable in class com.google.cloud.bigtable.grpc.async.AsyncExecutor
mutateRow(MutateRowRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableDataClient
Mutate a row atomically.
mutateRow(MutateRowRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGrpcClient
Mutate a row atomically.
mutateRowAsync(MutateRowRequest, long) - Method in class com.google.cloud.bigtable.grpc.async.AsyncExecutor
mutateRowAsync(MutateRowsRequest, long) - Method in class com.google.cloud.bigtable.grpc.async.AsyncExecutor
mutateRowAsync(MutateRowRequest) - Method in class com.google.cloud.bigtable.grpc.async.AsyncExecutor
mutateRowAsync(MutateRowRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableDataClient
Mutate a row atomically.
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 class com.google.cloud.bigtable.grpc.async.AsyncExecutor
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.

N

newBuilder() - Static method in class com.google.cloud.bigtable.grpc.scanner.FlatRow.Cell
 
newBuilder() - Static method in class com.google.cloud.bigtable.grpc.scanner.FlatRow
 
newCall(CallOptions) - Method in interface com.google.cloud.bigtable.grpc.async.BigtableAsyncRpc
Creates a ClientCall.
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.
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

onClose(Status, Metadata) - Method in class com.google.cloud.bigtable.grpc.async.AbstractRetryingRpcListener
onClose(Status, Metadata) - Method in class com.google.cloud.bigtable.grpc.scanner.OutstandingRequestCountListener
onClose(Status, Metadata) - Method in class com.google.cloud.bigtable.grpc.scanner.ReadRowsRetryListener
 
onClose(Status, Metadata) - Method in class com.google.cloud.bigtable.grpc.scanner.StreamObserverAdapter
onCompleted() - Method in class com.google.cloud.bigtable.grpc.scanner.ResponseQueueReader
onCompleted() - Method in class com.google.cloud.bigtable.grpc.scanner.RowMerger
All ReadRowsResponse have been processed, and HTTP OK was sent.
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(ResponseT) - Method in class com.google.cloud.bigtable.grpc.async.RetryingCollectingClientCallListener
onMessage(ResponseT) - Method in class com.google.cloud.bigtable.grpc.async.RetryingUnaryRpcCallListener
onMessage(ResponseT) - Method in class com.google.cloud.bigtable.grpc.scanner.OutstandingRequestCountListener
onMessage(ReadRowsResponse) - Method in class com.google.cloud.bigtable.grpc.scanner.ReadRowsRetryListener
onMessage(T) - Method in class com.google.cloud.bigtable.grpc.scanner.StreamObserverAdapter
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() - Method in class com.google.cloud.bigtable.grpc.async.AbstractRetryingRpcListener
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.RetryingCollectingClientCallListener
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.RetryingUnaryRpcCallListener
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.scanner.ReadRowsRetryListener
 
onRetryCompletion(long) - Method in class com.google.cloud.bigtable.grpc.async.RpcThrottler
onRetryCompletion.
OutstandingRequestCountListener<ResponseT> - Class in com.google.cloud.bigtable.grpc.scanner
A ClientCall.Listener that wraps a StreamObserver and decrements outstandingRequestCount when a message is received.
OutstandingRequestCountListener(StreamObserver<ResponseT>, AtomicInteger) - Constructor for class com.google.cloud.bigtable.grpc.scanner.OutstandingRequestCountListener
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.
performRetryIfStale() - Method in interface com.google.cloud.bigtable.grpc.async.RpcThrottler.RetryHandler
 

R

READ_FLAT_ROWS_ASYNC - Static variable in class com.google.cloud.bigtable.grpc.async.AsyncExecutor
READ_MODIFY_WRITE_ASYNC - Static variable in class com.google.cloud.bigtable.grpc.async.AsyncExecutor
READ_ROWS_ASYNC - Static variable in class com.google.cloud.bigtable.grpc.async.AsyncExecutor
readFlatRows(ReadRowsRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableDataClient
Perform a scan over FlatRows.
readFlatRows(ReadRowsRequest, StreamObserver<FlatRow>) - Method in interface com.google.cloud.bigtable.grpc.BigtableDataClient
Perform a streaming read of FlatRows.
readFlatRows(ReadRowsRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGrpcClient
Perform a scan over FlatRows.
readFlatRows(ReadRowsRequest, StreamObserver<FlatRow>) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGrpcClient
Perform a streaming read of FlatRows.
readFlatRowsAsync(ReadRowsRequest) - Method in class com.google.cloud.bigtable.grpc.async.AsyncExecutor
readFlatRowsAsync(ReadRowsRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableDataClient
Read multiple FlatRows into an in-memory list.
readFlatRowsAsync(ReadRowsRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGrpcClient
Read multiple FlatRows into an in-memory list.
readModifyWriteRow(ReadModifyWriteRowRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableDataClient
Perform an atomic read-modify-write operation on a row.
readModifyWriteRow(ReadModifyWriteRowRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGrpcClient
Perform an atomic read-modify-write operation on a row.
readModifyWriteRowAsync(ReadModifyWriteRowRequest, long) - Method in class com.google.cloud.bigtable.grpc.async.AsyncExecutor
readModifyWriteRowAsync(ReadModifyWriteRowRequest) - Method in class com.google.cloud.bigtable.grpc.async.AsyncExecutor
readModifyWriteRowAsync(ReadModifyWriteRowRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableDataClient
Perform an atomic read-modify-write operation on a row,
readModifyWriteRowAsync(ReadModifyWriteRowRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGrpcClient
Perform an atomic read-modify-write operation on a row,
readRows(ReadRowsRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableDataClient
Perform a scan over Rows.
readRows(ReadRowsRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGrpcClient
Perform a scan over Rows.
readRowsAsync(ReadRowsRequest, long) - Method in class com.google.cloud.bigtable.grpc.async.AsyncExecutor
readRowsAsync(ReadRowsRequest) - Method in class com.google.cloud.bigtable.grpc.async.AsyncExecutor
readRowsAsync(ReadRowsRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableDataClient
Read multiple Rows into an in-memory list.
readRowsAsync(ReadRowsRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGrpcClient
Read multiple Rows into an in-memory list.
ReadRowsRetryListener - Class in com.google.cloud.bigtable.grpc.scanner
An extension of AbstractRetryingRpcListener that manages retries for the readRows streaming RPC.
ReadRowsRetryListener(StreamObserver<FlatRow>, RetryOptions, ReadRowsRequest, BigtableAsyncRpc<ReadRowsRequest, ReadRowsResponse>, CallOptions, ScheduledExecutorService, Metadata) - Constructor for class com.google.cloud.bigtable.grpc.scanner.ReadRowsRetryListener
 
refreshCredentialsWithRetry() - Method in class com.google.cloud.bigtable.grpc.io.RefreshingOAuth2CredentialsInterceptor
Calls OAuth2Credentials.refreshAccessToken().
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, CredentialOptions, RetryOptions) - Constructor for class com.google.cloud.bigtable.grpc.io.RefreshingOAuth2CredentialsInterceptor
Constructor for RefreshingOAuth2CredentialsInterceptor.
registerOperationWithHeapSize(long) - Method in class com.google.cloud.bigtable.grpc.async.ResourceLimiter
Register an operation with the given size before sending.
registerOperationWithHeapSize(long) - Method in class com.google.cloud.bigtable.grpc.async.RpcThrottler
Register a new RPC operation.
registerRetry(RpcThrottler.RetryHandler) - Method in class com.google.cloud.bigtable.grpc.async.RpcThrottler
Registers a retry, if a retry is necessary, it will be complete before a call to awaitCompletion returns.
ResourceLimiter - Class in com.google.cloud.bigtable.grpc.async
This class limits access by RPCs to system resources
ResourceLimiter(long, int) - Constructor for class com.google.cloud.bigtable.grpc.async.ResourceLimiter
Constructor for ResourceLimiter.
ResponseQueueReader - Class in com.google.cloud.bigtable.grpc.scanner
Manages a queue of ResultQueueEntrys of FlatRow.
ResponseQueueReader(int) - Constructor for class com.google.cloud.bigtable.grpc.scanner.ResponseQueueReader
Constructor for ResponseQueueReader.
resultQueue - Variable in class com.google.cloud.bigtable.grpc.scanner.ResponseQueueReader
 
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, ScanHandler) - 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.AbstractRetryingRpcListener
 
RetryingCollectingClientCallListener<RequestT,ResponseT> - Class in com.google.cloud.bigtable.grpc.async
RetryingCollectingClientCallListener class.
RetryingCollectingClientCallListener(RetryOptions, RequestT, BigtableAsyncRpc<RequestT, ResponseT>, CallOptions, ScheduledExecutorService, Metadata) - Constructor for class com.google.cloud.bigtable.grpc.async.RetryingCollectingClientCallListener
Constructor for RetryingCollectingClientCallListener.
RetryingUnaryRpcCallListener<RequestT,ResponseT> - Class in com.google.cloud.bigtable.grpc.async
A AsyncFunction that retries a BigtableAsyncRpc request.
RetryingUnaryRpcCallListener(RetryOptions, RequestT, BigtableAsyncRpc<RequestT, ResponseT>, CallOptions, ScheduledExecutorService, Metadata) - Constructor for class com.google.cloud.bigtable.grpc.async.RetryingUnaryRpcCallListener
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
Constructor for RetryOptions.
retryOptions - Variable in class com.google.cloud.bigtable.grpc.async.AbstractRetryingRpcListener
 
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
 
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.
rpc - Variable in class com.google.cloud.bigtable.grpc.async.AbstractRetryingRpcListener
 
RpcThrottler - Class in com.google.cloud.bigtable.grpc.async
Throttles the number of RPCs that are outstanding at any point in time.
RpcThrottler(ResourceLimiter) - Constructor for class com.google.cloud.bigtable.grpc.async.RpcThrottler
Constructor for RpcThrottler.
RpcThrottler.RetryHandler - Interface in com.google.cloud.bigtable.grpc.async
 
rpcTimerContext - Variable in class com.google.cloud.bigtable.grpc.async.AbstractRetryingRpcListener
 
run() - Method in class com.google.cloud.bigtable.grpc.async.AbstractRetryingRpcListener
run() - Method in class com.google.cloud.bigtable.grpc.async.RetryingCollectingClientCallListener
run() - Method in class com.google.cloud.bigtable.grpc.scanner.ReadRowsRetryListener
 

S

sampleRowKeys(SampleRowKeysRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableDataClient
Sample row keys from a table.
sampleRowKeys(SampleRowKeysRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGrpcClient
Sample row keys from a table.
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(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
An IOException that presents timeout when reading response.
ScanTimeoutException(String) - Constructor for exception com.google.cloud.bigtable.grpc.scanner.ScanTimeoutException
Constructor for ScanTimeoutException.
SERVICE_ACCOUNT_JSON_ENV_VARIABLE - Static variable in class com.google.cloud.bigtable.config.CredentialOptions
Constant SERVICE_ACCOUNT_JSON_ENV_VARIABLE="GOOGLE_APPLICATION_CREDENTIALS"
set(RespT) - Method in class com.google.cloud.bigtable.grpc.async.AbstractRetryingRpcListener.GrpcFuture
 
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.
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
 
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
setClusterId(String) - Method in class com.google.cloud.bigtable.config.BigtableOptions.Builder
 
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 clustr
setCredentialOptions(CredentialOptions) - Method in class com.google.cloud.bigtable.config.BigtableOptions.Builder
 
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.AbstractRetryingRpcListener.GrpcFuture
 
setException(Exception) - Method in class com.google.cloud.bigtable.grpc.async.AbstractRetryingRpcListener
 
setException(Exception) - Method in class com.google.cloud.bigtable.grpc.scanner.ReadRowsRetryListener
 
setHttpTransportFactory(HttpTransportFactory) - Static method in class com.google.cloud.bigtable.config.CredentialFactory
Allow for an override of the credentials HttpTransportFactory.
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.
setInstanceAdminHost(String) - Method in class com.google.cloud.bigtable.config.BigtableOptions.Builder
 
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
The amount of milliseconds to wait before issuing a client side timeout for long RPCs.
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.
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.
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.
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.
setTableAdminHost(String) - Method in class com.google.cloud.bigtable.config.BigtableOptions.Builder
 
setTimeoutMs(int) - Method in class com.google.cloud.bigtable.config.CallOptionsConfig.Builder
Deprecated.
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.
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.
setZoneId(String) - Method in class com.google.cloud.bigtable.config.BigtableOptions.Builder
 
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.
start() - Method in class com.google.cloud.bigtable.grpc.async.AbstractRetryingRpcListener
Initial execution of the RPC.
start(ClientCall<REQUEST, RESPONSE>, REQUEST, ClientCall.Listener<RESPONSE>, Metadata) - Method in interface com.google.cloud.bigtable.grpc.async.BigtableAsyncRpc
Creates a ClientCall.
STATS - Static variable in class com.google.cloud.bigtable.grpc.io.ChannelPool
 
StreamObserverAdapter<T> - Class in com.google.cloud.bigtable.grpc.scanner
Adapts a StreamObserver to a ClientCall.Listener.
StreamObserverAdapter(ClientCall<?, T>, StreamObserver<T>) - Constructor for class com.google.cloud.bigtable.grpc.scanner.StreamObserverAdapter
Constructor for StreamObserverAdapter.
syncRefresh() - Method in class com.google.cloud.bigtable.grpc.io.RefreshingOAuth2CredentialsInterceptor
syncRefresh.

T

TABLE_SEPARATOR - Static variable in class com.google.cloud.bigtable.grpc.BigtableInstanceName
Constant TABLE_SEPARATOR="/tables/"
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
 
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
Create a fully qualified snapshot name based on the the clusterName and the snapshotId.
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
Get the instance name.
toString() - Method in class com.google.cloud.bigtable.grpc.BigtableSnapshotName
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.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

U

update(long, TimeUnit) - Method in interface com.google.cloud.bigtable.metrics.Timer
Adds a recorded duration.
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.GoogleCloudResourcePrefixInterceptor
 
updateInstance(Instance) - Method in interface com.google.cloud.bigtable.grpc.BigtableInstanceClient
Updates an instance within a project.
updateInstance(Instance) - Method in class com.google.cloud.bigtable.grpc.BigtableInstanceGrpcClient
Updates an instance within a project.
updateLastFoundKey(ByteString) - Method in class com.google.cloud.bigtable.grpc.scanner.ReadRowsRetryListener
 
USE_TIMEOUT_DEFAULT - Static variable in class com.google.cloud.bigtable.config.CallOptionsConfig
Constant USE_TIMEOUT_DEFAULT=false
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.
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.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.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.
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
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
 
wrap(byte[]) - Static method in class com.google.cloud.bigtable.util.ByteStringer
Wraps a byte array in a ByteString without copying it.
wrap(byte[], int, int) - Static method in class com.google.cloud.bigtable.util.ByteStringer
Wraps a byte array in a ByteString without copying it.
wrap(byte[]) - Static method in class com.google.cloud.bigtable.util.ZeroCopyByteStringUtil
Wraps a byte array in a ByteString without copying it.

Z

ZeroCopyByteStringUtil - Class in com.google.cloud.bigtable.util
Helper class to extract byte arrays from ByteString without copy.
ZeroCopyByteStringUtil() - Constructor for class com.google.cloud.bigtable.util.ZeroCopyByteStringUtil
 
A B C D E F G H I J L M N O P R S T U V W Z 
Skip navigation links