Index (Cloud Bigtable HBase Client for Java 1.12.0 API)

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

A

abort(String, Throwable) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
abort(String, Throwable) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableConnection
abortProcedure(long, boolean) - Method in class com.google.cloud.bigtable.hbase1_x.BigtableAdmin
 
abortProcedure(long, boolean) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
 
abortProcedure(long, boolean) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
abortProcedureAsync(long, boolean) - Method in class com.google.cloud.bigtable.hbase1_x.BigtableAdmin
 
abortProcedureAsync(long, boolean) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
 
AbstractBigtableAdmin - Class in org.apache.hadoop.hbase.client
Abstract AbstractBigtableAdmin class.
AbstractBigtableAdmin(CommonConnection) - Constructor for class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
Constructor for AbstractBigtableAdmin.
AbstractBigtableConnection - Class in org.apache.hadoop.hbase.client
Abstract AbstractBigtableConnection class.
AbstractBigtableConnection(Configuration) - Constructor for class org.apache.hadoop.hbase.client.AbstractBigtableConnection
Constructor for AbstractBigtableConnection.
AbstractBigtableConnection(Configuration, boolean, ExecutorService, User) - Constructor for class org.apache.hadoop.hbase.client.AbstractBigtableConnection
The constructor called from ConnectionFactory.createConnection(Configuration) and in its many forms via reflection with this specific signature.
AbstractBigtableRegionLocator - Class in com.google.cloud.bigtable.hbase
AbstractBigtableRegionLocator class.
AbstractBigtableRegionLocator(TableName, BigtableOptions, IBigtableDataClient) - Constructor for class com.google.cloud.bigtable.hbase.AbstractBigtableRegionLocator
 
AbstractBigtableTable - Class in com.google.cloud.bigtable.hbase
BigtableTable class.
AbstractBigtableTable(AbstractBigtableConnection, HBaseRequestAdapter) - Constructor for class com.google.cloud.bigtable.hbase.AbstractBigtableTable
Constructed by BigtableConnection
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
 
ACCEPT_ALL_FILTER - Static variable in class com.google.cloud.bigtable.hbase.adapters.filters.FilterAdapterHelper
A RowFilter that will match all cells.
adapt(HColumnDescriptor) - Method in class com.google.cloud.bigtable.hbase.adapters.admin.ColumnDescriptorAdapter
Adapt a single instance of an HBase HColumnDescriptor to an instance of ColumnFamily.Builder.
adapt(ColumnFamily) - Method in class com.google.cloud.bigtable.hbase.adapters.admin.ColumnDescriptorAdapter
Convert a Bigtable ColumnFamily to an HBase HColumnDescriptor.
adapt(HTableDescriptor, CreateTableRequest) - Static method in class com.google.cloud.bigtable.hbase.adapters.admin.TableAdapter
adapt.
adapt(HTableDescriptor, byte[][]) - Static method in class com.google.cloud.bigtable.hbase.adapters.admin.TableAdapter
 
adapt(Table) - Method in class com.google.cloud.bigtable.hbase.adapters.admin.TableAdapter
adapt.
adapt(Append, ReadModifyWriteRow) - Method in class com.google.cloud.bigtable.hbase.adapters.AppendAdapter
Adapt a single HBase Operation to a single Bigtable generated message.
adapt(Delete, MutationApi<?>) - Method in class com.google.cloud.bigtable.hbase.adapters.DeleteAdapter
Converts an HBase Row which represents a set of changes to a single row from an HBase perspective to a Google Cloud Java MutationApi which represent the set of changes.
adapt(FilterAdapterContext, BigtableFilter) - Method in class com.google.cloud.bigtable.hbase.adapters.filters.BigtableFilterAdapter
 
adapt(ResultScanner<FlatRow>, Span) - Method in class com.google.cloud.bigtable.hbase.adapters.filters.BigtableWhileMatchResultScannerAdapter
adapt.
adapt(FilterAdapterContext, ColumnCountGetFilter) - Method in class com.google.cloud.bigtable.hbase.adapters.filters.ColumnCountGetFilterAdapter
Adapt the given filter.
adapt(FilterAdapterContext, ColumnPaginationFilter) - Method in class com.google.cloud.bigtable.hbase.adapters.filters.ColumnPaginationFilterAdapter
Adapt the given filter.
adapt(FilterAdapterContext, ColumnPrefixFilter) - Method in class com.google.cloud.bigtable.hbase.adapters.filters.ColumnPrefixFilterAdapter
Adapt the given filter.
adapt(FilterAdapterContext, ColumnRangeFilter) - Method in class com.google.cloud.bigtable.hbase.adapters.filters.ColumnRangeFilterAdapter
Adapt the given filter.
adapt(FilterAdapterContext, FamilyFilter) - Method in class com.google.cloud.bigtable.hbase.adapters.filters.FamilyFilterAdapter
Adapt the given filter.
adapt(FilterAdapterContext, FilterList) - Method in class com.google.cloud.bigtable.hbase.adapters.filters.FilterListAdapter
Adapt the given filter.
adapt(FilterAdapterContext, FirstKeyOnlyFilter) - Method in class com.google.cloud.bigtable.hbase.adapters.filters.FirstKeyOnlyFilterAdapter
Adapt the given filter.
adapt(FilterAdapterContext, FuzzyRowFilter) - Method in class com.google.cloud.bigtable.hbase.adapters.filters.FuzzyRowFilterAdapter
Adapt the given filter.
adapt(FilterAdapterContext, KeyOnlyFilter) - Method in class com.google.cloud.bigtable.hbase.adapters.filters.KeyOnlyFilterAdapter
Adapt the given filter.
adapt(FilterAdapterContext, MultipleColumnPrefixFilter) - Method in class com.google.cloud.bigtable.hbase.adapters.filters.MultipleColumnPrefixFilterAdapter
Adapt the given filter.
adapt(FilterAdapterContext, MultiRowRangeFilter) - Method in class com.google.cloud.bigtable.hbase.adapters.filters.MultiRowRangeFilterAdapter
 
adapt(FilterAdapterContext, PageFilter) - Method in class com.google.cloud.bigtable.hbase.adapters.filters.PageFilterAdapter
Adapt the given filter.
adapt(FilterAdapterContext, PrefixFilter) - Method in class com.google.cloud.bigtable.hbase.adapters.filters.PrefixFilterAdapter
Adapt the given filter.
adapt(FilterAdapterContext, QualifierFilter) - Method in class com.google.cloud.bigtable.hbase.adapters.filters.QualifierFilterAdapter
Adapt the given filter.
adapt(FilterAdapterContext, RandomRowFilter) - Method in class com.google.cloud.bigtable.hbase.adapters.filters.RandomRowFilterAdapter
Adapt the given filter.
adapt(FilterAdapterContext, RowFilter) - Method in class com.google.cloud.bigtable.hbase.adapters.filters.RowFilterAdapter
Adapt the given filter.
adapt(FilterAdapterContext, SingleColumnValueExcludeFilter) - Method in class com.google.cloud.bigtable.hbase.adapters.filters.SingleColumnValueExcludeFilterAdapter
Adapt the given filter.
adapt(FilterAdapterContext, SingleColumnValueFilter) - Method in class com.google.cloud.bigtable.hbase.adapters.filters.SingleColumnValueFilterAdapter
SingleColumnValueFilter is a filter that will return a row if a family/qualifier value matches some condition.
adapt(FilterAdapterContext, Filter) - Method in class com.google.cloud.bigtable.hbase.adapters.filters.SingleFilterAdapter
Adapt the untyped hbaseFilter instance into a RowFilter.
adapt(FilterAdapterContext, TimestampRangeFilter) - Method in class com.google.cloud.bigtable.hbase.adapters.filters.TimestampRangeFilterAdapter
 
adapt(FilterAdapterContext, TimestampsFilter) - Method in class com.google.cloud.bigtable.hbase.adapters.filters.TimestampsFilterAdapter
Adapt the given filter.
adapt(FilterAdapterContext, S) - Method in interface com.google.cloud.bigtable.hbase.adapters.filters.TypedFilterAdapter
Adapt the given filter.
adapt(FilterAdapterContext, ValueFilter) - Method in class com.google.cloud.bigtable.hbase.adapters.filters.ValueFilterAdapter
Adapt the given filter.
adapt(FilterAdapterContext, WhileMatchFilter) - Method in class com.google.cloud.bigtable.hbase.adapters.filters.WhileMatchFilterAdapter
Adapt the given filter.
adapt(Mutation, MutationApi<?>) - Method in class com.google.cloud.bigtable.hbase.adapters.HBaseMutationAdapter
Converts an HBase Row which represents a set of changes to a single row from an HBase perspective to a Google Cloud Java MutationApi which represent the set of changes.
adapt(Delete) - Method in class com.google.cloud.bigtable.hbase.adapters.HBaseRequestAdapter
adapt.
adapt(Delete, MutationApi<?>) - Method in class com.google.cloud.bigtable.hbase.adapters.HBaseRequestAdapter
adapt.
adapt(Get) - Method in class com.google.cloud.bigtable.hbase.adapters.HBaseRequestAdapter
adapt.
adapt(Scan) - Method in class com.google.cloud.bigtable.hbase.adapters.HBaseRequestAdapter
adapt.
adapt(Append) - Method in class com.google.cloud.bigtable.hbase.adapters.HBaseRequestAdapter
adapt.
adapt(Increment) - Method in class com.google.cloud.bigtable.hbase.adapters.HBaseRequestAdapter
adapt.
adapt(Put) - Method in class com.google.cloud.bigtable.hbase.adapters.HBaseRequestAdapter
adapt.
adapt(Put, MutationApi<?>) - Method in class com.google.cloud.bigtable.hbase.adapters.HBaseRequestAdapter
adapt.
adapt(RowMutations) - Method in class com.google.cloud.bigtable.hbase.adapters.HBaseRequestAdapter
adapt.
adapt(RowMutations, MutationApi<?>) - Method in class com.google.cloud.bigtable.hbase.adapters.HBaseRequestAdapter
adapt.
adapt(Mutation) - Method in class com.google.cloud.bigtable.hbase.adapters.HBaseRequestAdapter
adapt.
adapt(Increment, ReadModifyWriteRow) - Method in class com.google.cloud.bigtable.hbase.adapters.IncrementAdapter
Adapt a single HBase Operation to a single Bigtable generated message.
adapt(T, MutationApi<?>) - Method in class com.google.cloud.bigtable.hbase.adapters.MutationAdapter
Converts an HBase Row which represents a set of changes to a single row from an HBase perspective to a Google Cloud Java MutationApi which represent the set of changes.
adapt(T, U) - Method in interface com.google.cloud.bigtable.hbase.adapters.OperationAdapter
Adapt a single HBase Operation to a single Bigtable generated message.
adapt(Put, MutationApi<?>) - Method in class com.google.cloud.bigtable.hbase.adapters.PutAdapter
Converts an HBase Row which represents a set of changes to a single row from an HBase perspective to a Google Cloud Java MutationApi which represent the set of changes.
adapt(ResultScanner<T>, Span) - Method in class com.google.cloud.bigtable.hbase.adapters.read.BigtableResultScannerAdapter
adapt.
adapt(Get, ReadHooks, Query) - Method in class com.google.cloud.bigtable.hbase.adapters.read.GetAdapter
adapt.
adapt(T, ReadHooks, Query) - Method in interface com.google.cloud.bigtable.hbase.adapters.read.ReadOperationAdapter
adapt.
adapt(Scan, ReadHooks, Query) - Method in class com.google.cloud.bigtable.hbase.adapters.read.ScanAdapter
adapt.
adapt(RowMutations, MutationApi<?>) - Method in class com.google.cloud.bigtable.hbase.adapters.RowMutationsAdapter
Converts an HBase Row which represents a set of changes to a single row from an HBase perspective to a Google Cloud Java MutationApi which represent the set of changes.
adapt(T, MutationApi<?>) - Method in class com.google.cloud.bigtable.hbase.adapters.UnsupportedMutationAdapter
Converts an HBase Row which represents a set of changes to a single row from an HBase perspective to a Google Cloud Java MutationApi which represent the set of changes.
adapt(TableDescriptor, byte[][]) - Static method in class com.google.cloud.bigtable.hbase2_x.adapters.admin.TableAdapter2x
 
adapt(Table) - Method in class com.google.cloud.bigtable.hbase2_x.adapters.admin.TableAdapter2x
adapt.
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
 
adaptEntry(Delete) - Method in class com.google.cloud.bigtable.hbase.adapters.HBaseRequestAdapter
adapt.
adaptEntry(Put) - Method in class com.google.cloud.bigtable.hbase.adapters.HBaseRequestAdapter
adaptEntry.
adaptEntry(RowMutations) - Method in class com.google.cloud.bigtable.hbase.adapters.HBaseRequestAdapter
adaptEntry.
Adapters - Class in com.google.cloud.bigtable.hbase.adapters
Manages all Adapters
adaptFilter(FilterAdapterContext, Filter) - Method in class com.google.cloud.bigtable.hbase.adapters.filters.FilterAdapter
Adapt an HBase filter into a Cloud Bigtable Rowfilter.
adaptResponse(FlatRow) - Method in class com.google.cloud.bigtable.hbase.adapters.read.FlatRowAdapter
Transform an Bigtable server response to an HBase Result instance.
adaptResponse(Row) - Method in class com.google.cloud.bigtable.hbase.adapters.read.RowAdapter
Transform an Bigtable server response to an HBase Result instance.
adaptResponse(T) - Method in interface com.google.cloud.bigtable.hbase.adapters.ResponseAdapter
Transform an Bigtable server response to an HBase Result instance.
adaptResponse(List<KeyOffset>) - Method in class com.google.cloud.bigtable.hbase.adapters.SampledRowKeysAdapter
adaptResponse.
adaptToRow(Result) - Method in class com.google.cloud.bigtable.hbase.adapters.read.FlatRowAdapter
Convert a Result to a FlatRow.
add(RowMutation) - Method in interface com.google.cloud.bigtable.core.IBulkMutation
Adds a RowMutation 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(RowMutation) - Method in class com.google.cloud.bigtable.grpc.async.BulkMutationGCJClient
Adds a RowMutation to the underlying IBulkMutation mechanism.
add(RowMutation) - Method in class com.google.cloud.bigtable.grpc.async.BulkMutationWrapper
Adds a RowMutation 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.
add(HColumnDescriptor) - Method in class com.google.cloud.bigtable.hbase.util.ModifyTableBuilder
 
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
 
addColumn(TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
addColumn(String, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
Deprecated.
addColumnFamily(TableName, ColumnFamilyDescriptor) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
addColumnFamily(TableName, ColumnFamilyDescriptor) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
addColumnFamilyAsync(TableName, ColumnFamilyDescriptor) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
 
addFilterAndArguments(Configuration, Class<? extends Filter>, List<String>) - Static method in class com.google.cloud.bigtable.mapreduce.Import
Add a Filter to be instantiated on import
ADDITIONAL_RETRY_CODES - Static variable in class com.google.cloud.bigtable.hbase.BigtableOptionsFactory
Key to set to a comma separated list of grpc codes to retry.
addPutToKv(Put, Cell) - Method in class com.google.cloud.bigtable.mapreduce.Import.Importer
 
addRange(byte[], byte[]) - Method in class com.google.cloud.bigtable.hbase.BigtableExtendedScan
Adds a range to scan.
addRange(RowRange) - Method in class com.google.cloud.bigtable.hbase.BigtableExtendedScan
Adds an arbitrary RowRange to the request.
addRangeWithPrefix(byte[]) - Method in class com.google.cloud.bigtable.hbase.BigtableExtendedScan
Creates a RowRange based on a prefix.
addReplicationPeer(String, ReplicationPeerConfig, boolean) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
 
addReplicationPeer(String, ReplicationPeerConfig) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
addReplicationPeer(String, ReplicationPeerConfig, boolean) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
 
addReplicationPeerAsync(String, ReplicationPeerConfig) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
 
addReplicationPeerAsync(String, ReplicationPeerConfig, boolean) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
 
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.
addRowKey(byte[]) - Method in class com.google.cloud.bigtable.hbase.BigtableExtendedScan
Add a single row key to the output.
addSplitKeys(byte[][], CreateTableRequest) - Static method in class com.google.cloud.bigtable.hbase.adapters.admin.TableAdapter
 
addStatusToRetryOn(Status.Code) - Method in class com.google.cloud.bigtable.config.RetryOptions.Builder
 
addWhileMatchFilter(WhileMatchFilter) - Method in class com.google.cloud.bigtable.hbase.adapters.filters.FilterAdapterContext
addWhileMatchFilter.
ALL_BYTE_BYTES - Static variable in class com.google.cloud.bigtable.hbase.adapters.read.ReaderExpressionHelper
Constant ANY_BYTE_BYTES=Bytes.toBytes(ANY_BYTE)
ALL_BYTES - Static variable in class com.google.cloud.bigtable.hbase.adapters.read.ReaderExpressionHelper
Constant ALL_BYTES="\\C*"
ALL_QUALIFIERS_BYTES - Static variable in class com.google.cloud.bigtable.hbase.adapters.read.ReaderExpressionHelper
Constant ALL_QUALIFIERS_BYTES=Bytes.toBytes(ALL_QUALIFIERS)
ALLOW_NO_TIMESTAMP_RETRIES_KEY - Static variable in class com.google.cloud.bigtable.hbase.BigtableOptionsFactory
By default, the hbase client will set the timestamp on the client side before sending a Put if it's not set already.
allowRetriesWithoutTimestamp() - Method in class com.google.cloud.bigtable.config.RetryOptions
Should retries be allowed even if a timestamp isn't set?
ANY_BYTE - Static variable in class com.google.cloud.bigtable.hbase.adapters.read.ReaderExpressionHelper
Constant ANY_BYTE="\\C"
ANY_BYTE_BYTES - Static variable in class com.google.cloud.bigtable.hbase.adapters.read.ReaderExpressionHelper
Constant ANY_BYTE_BYTES=Bytes.toBytes(ANY_BYTE)
ANY_BYTES - Static variable in class com.google.cloud.bigtable.hbase.adapters.read.ReaderExpressionHelper
Constant ANY_BYTES="\\C+"
ApiFutureUtil - Class in com.google.cloud.bigtable.util
 
ApiFutureUtil() - Constructor for class com.google.cloud.bigtable.util.ApiFutureUtil
 
APP_PROFILE_ID_KEY - Static variable in class com.google.cloud.bigtable.hbase.BigtableOptionsFactory
Constant APP_PROFILE_ID_KEY="google.bigtable.app_profile.id"
append(Append) - Method in class com.google.cloud.bigtable.hbase.AbstractBigtableTable
append(Append) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncTable
APPEND_ADAPTER - Static variable in class com.google.cloud.bigtable.hbase.adapters.Adapters
Constant APPEND_ADAPTER
AppendAdapter - Class in com.google.cloud.bigtable.hbase.adapters
Adapter for HBase Appends operations to Bigtable ReadModifyWriteRowRequest.Builder.
AppendAdapter() - Constructor for class com.google.cloud.bigtable.hbase.adapters.AppendAdapter
 
appendReplicationPeerTableCFs(String, Map<TableName, List<String>>) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
 
appendReplicationPeerTableCFs(String, Map<TableName, List<String>>) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
 
applyPreSendHook(Query) - Method in class com.google.cloud.bigtable.hbase.adapters.read.DefaultReadHooks
Apply all pre-send hooks to the given request.
applyPreSendHook(Query) - Method in interface com.google.cloud.bigtable.hbase.adapters.read.ReadHooks
Apply all pre-send hooks to the given request.
assign(byte[]) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
 
assign(byte[]) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
asyncConfigure(Configuration) - Static method in class com.google.cloud.bigtable.hbase.BigtableConfiguration
Configuration for getting a org.apache.hadoop.hbase.client.AsyncConnection.
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

balance() - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
 
balance(boolean) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
 
balance(boolean) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
 
balancer(boolean) - Method in class com.google.cloud.bigtable.hbase1_x.BigtableAdmin
 
balancer() - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
balancerSwitch(boolean, boolean) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
 
balancerSwitch(boolean) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
 
batch(List<? extends Row>, Object[]) - Method in class com.google.cloud.bigtable.hbase.AbstractBigtableTable
batch(List<? extends Row>) - Method in class com.google.cloud.bigtable.hbase.AbstractBigtableTable
Deprecated.
batch(List<? extends Row>, Object[]) - Method in class com.google.cloud.bigtable.hbase.BatchExecutor
batch.
batch(List<? extends Row>) - Method in class com.google.cloud.bigtable.hbase.BatchExecutor
batch.
batch(List<? extends Row>) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncTable
batchCallback(List<? extends Row>, Object[], Batch.Callback<R>) - Method in class com.google.cloud.bigtable.hbase.AbstractBigtableTable
batchCallback(List<? extends Row>, Batch.Callback<R>) - Method in class com.google.cloud.bigtable.hbase.AbstractBigtableTable
Deprecated.
batchCallback(List<? extends Row>, Object[], Batch.Callback<R>) - Method in class com.google.cloud.bigtable.hbase.BatchExecutor
batchCoprocessorService(Descriptors.MethodDescriptor, Message, byte[], byte[], R) - Method in class com.google.cloud.bigtable.hbase.AbstractBigtableTable
batchCoprocessorService(Descriptors.MethodDescriptor, Message, byte[], byte[], R, Batch.Callback<R>) - Method in class com.google.cloud.bigtable.hbase.AbstractBigtableTable
BatchExecutor - Class in com.google.cloud.bigtable.hbase
Class to help BigtableTable with batch operations on an BigtableClient, such as Table.batch(List, Object[]).
BatchExecutor(BigtableSession, HBaseRequestAdapter) - Constructor for class com.google.cloud.bigtable.hbase.BatchExecutor
Constructor for BatchExecutor.
batchThreadPool - Variable in class com.google.cloud.bigtable.grpc.BigtableSessionSharedThreadPools
This is used to do i/o work.
batchTimer - Variable in class com.google.cloud.bigtable.hbase.BatchExecutor
 
beforeStart(ClientCallStreamObserver<ReadRowsRequest>) - Method in class com.google.cloud.bigtable.grpc.scanner.ResponseQueueReader
 
beginFilterList(FilterList) - Method in class com.google.cloud.bigtable.hbase.adapters.filters.FilterAdapterContext
beginFilterList.
bigtable2hbase(long) - Static method in class com.google.cloud.bigtable.hbase.util.TimestampConverter
 
BIGTABLE_ADMIN_HOST_DEFAULT - Static variable in class com.google.cloud.bigtable.config.BigtableOptions
Constant BIGTABLE_ADMIN_HOST_DEFAULT="bigtableadmin.googleapis.com"
BIGTABLE_ADMIN_HOST_KEY - Static variable in class com.google.cloud.bigtable.hbase.BigtableOptionsFactory
Constant BIGTABLE_ADMIN_HOST_KEY="google.bigtable.admin.endpoint.host"
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
Constant BIGTABLE_ASYNC_MUTATOR_COUNT_DEFAULT=2
BIGTABLE_ASYNC_MUTATOR_COUNT_KEY - Static variable in class com.google.cloud.bigtable.hbase.BigtableOptionsFactory
The number of asynchronous workers to use for buffered mutator operations.
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_BUFFERED_MUTATOR_ENABLE_THROTTLING - Static variable in class com.google.cloud.bigtable.hbase.BigtableOptionsFactory
Turn on a feature that will reduce the likelihood of BufferedMutator overloading a Cloud Bigtable cluster.
BIGTABLE_BUFFERED_MUTATOR_MAX_MEMORY_KEY - Static variable in class com.google.cloud.bigtable.hbase.BigtableOptionsFactory
The maximum amount of memory to be used for asynchronous buffered mutator RPCs.
BIGTABLE_BUFFERED_MUTATOR_THROTTLING_THRESHOLD_MILLIS - Static variable in class com.google.cloud.bigtable.hbase.BigtableOptionsFactory
Tweak the throttling
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_AUTOFLUSH_MS_KEY - Static variable in class com.google.cloud.bigtable.hbase.BigtableOptionsFactory
Constant BIGTABLE_BULK_AUTOFLUSH_MS_KEY="google.bigtable.bulk.autoflush.ms"
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 - Static variable in class com.google.cloud.bigtable.hbase.BigtableOptionsFactory
Constant BIGTABLE_BULK_MAX_REQUEST_SIZE_BYTES="google.bigtable.bulk.max.request.size.b"{trunked}
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 - Static variable in class com.google.cloud.bigtable.hbase.BigtableOptionsFactory
Constant BIGTABLE_BULK_MAX_ROW_KEY_COUNT="google.bigtable.bulk.max.row.key.count"
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
 
BIGTABLE_DATA_CHANNEL_COUNT_DEFAULT - Static variable in class com.google.cloud.bigtable.config.BigtableOptions
Constant BIGTABLE_DATA_CHANNEL_COUNT_DEFAULT=getDefaultDataChannelCount()
BIGTABLE_DATA_CHANNEL_COUNT_KEY - Static variable in class com.google.cloud.bigtable.hbase.BigtableOptionsFactory
The number of grpc channels to open for asynchronous processing such as puts.
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_EMULATOR_HOST_KEY - Static variable in class com.google.cloud.bigtable.hbase.BigtableOptionsFactory
Constant BIGTABLE_HOST_KEY="google.bigtable.emulator.endpoint.host".
BIGTABLE_HBASE_CLIENT_ASYNC_CONNECTION_CLASS - Static variable in class com.google.cloud.bigtable.hbase.BigtableConfiguration
 
BIGTABLE_HBASE_CLIENT_ASYNC_REGISTRY_CLASS - Static variable in class com.google.cloud.bigtable.hbase.BigtableConfiguration
 
BIGTABLE_HOST_KEY - Static variable in class com.google.cloud.bigtable.hbase.BigtableOptionsFactory
Constant BIGTABLE_HOST_KEY="google.bigtable.endpoint.host"
BIGTABLE_LONG_RPC_TIMEOUT_MS_KEY - Static variable in class com.google.cloud.bigtable.hbase.BigtableOptionsFactory
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_MUTATE_RPC_TIMEOUT_MS_KEY - Static variable in class com.google.cloud.bigtable.hbase.BigtableOptionsFactory
If timeouts are set, how many milliseconds should pass before a DEADLINE_EXCEEDED for a long mutation.
BIGTABLE_NAMESPACE_WARNING_KEY - Static variable in class com.google.cloud.bigtable.hbase.BigtableOptionsFactory
Allow namespace methods to be no-ops
BIGTABLE_NULL_CREDENTIAL_ENABLE_DEFAULT - Static variable in class com.google.cloud.bigtable.hbase.BigtableOptionsFactory
Constant BIGTABLE_NULL_CREDENTIAL_ENABLE_DEFAULT=false
BIGTABLE_NULL_CREDENTIAL_ENABLE_KEY - Static variable in class com.google.cloud.bigtable.hbase.BigtableOptionsFactory
Key to allow unit tests to proceed with an invalid credential configuration.
BIGTABLE_PORT_DEFAULT - Static variable in class com.google.cloud.bigtable.config.BigtableOptions
Constant BIGTABLE_PORT_DEFAULT=443
BIGTABLE_PORT_KEY - Static variable in class com.google.cloud.bigtable.hbase.BigtableOptionsFactory
Constant BIGTABLE_PORT_KEY="google.bigtable.endpoint.port"
BIGTABLE_READ_RPC_TIMEOUT_MS_KEY - Static variable in class com.google.cloud.bigtable.hbase.BigtableOptionsFactory
If timeouts are set, how many milliseconds should pass before a DEADLINE_EXCEEDED for a long read.
BIGTABLE_RESULT_SCAN_ADAPTER - Static variable in class com.google.cloud.bigtable.hbase.adapters.Adapters
Constant BIGTABLE_RESULT_SCAN_ADAPTER
BIGTABLE_RPC_TIMEOUT_MS_KEY - Static variable in class com.google.cloud.bigtable.hbase.BigtableOptionsFactory
If timeouts are set, how many milliseconds should pass before a DEADLINE_EXCEEDED? Currently, this feature is experimental.
BIGTABLE_SERVICE_ACCOUNT_EMAIL_KEY - Static variable in class com.google.cloud.bigtable.hbase.BigtableOptionsFactory
Key to set when using P12 keyfile authentication.
BIGTABLE_SERVICE_ACCOUNT_JSON_KEYFILE_LOCATION_KEY - Static variable in class com.google.cloud.bigtable.hbase.BigtableOptionsFactory
Key to set to a location where a json security credentials file can be found.
BIGTABLE_SERVICE_ACCOUNT_JSON_VALUE_KEY - Static variable in class com.google.cloud.bigtable.hbase.BigtableOptionsFactory
Key to set to a json security credentials string.
BIGTABLE_SERVICE_ACCOUNT_P12_KEYFILE_LOCATION_KEY - Static variable in class com.google.cloud.bigtable.hbase.BigtableOptionsFactory
Key to set to a location where a P12 keyfile can be found that corresponds to the provided service account email address.
BIGTABLE_SNAPSHOT_CLUSTER_ID_KEY - Static variable in class com.google.cloud.bigtable.hbase.BigtableOptionsFactory
Constant BIGTABLE_SNAPSHOT_CLUSTER_ID_KEY="google.bigtable.snapshot.cluster.id"
BIGTABLE_SNAPSHOT_DEFAULT_TTL_SECS_KEY - Static variable in class com.google.cloud.bigtable.hbase.BigtableOptionsFactory
Constant BIGTABLE_SNAPSHOT_DEFAULT_TTL_SECS_KEY="google.bigtable.snapshot.default.ttl.secs"
BIGTABLE_USE_BATCH - Static variable in class com.google.cloud.bigtable.hbase.BigtableOptionsFactory
Constant BIGTABLE_USE_BATCH="google.bigtable.use.batch"
BIGTABLE_USE_BULK_API - Static variable in class com.google.cloud.bigtable.hbase.BigtableOptionsFactory
Constant BIGTABLE_USE_BULK_API="google.bigtable.use.bulk.api"
BIGTABLE_USE_CACHED_DATA_CHANNEL_POOL - Static variable in class com.google.cloud.bigtable.hbase.BigtableOptionsFactory
Constant BIGTABLE_USE_CACHED_DATA_CHANNEL_POOL="google.bigtable.use.cached.data.channel.pool"
BIGTABLE_USE_GCJ_CLIENT - Static variable in class com.google.cloud.bigtable.hbase.BigtableOptionsFactory
A flag to decide which implementation to use for data & admin operation
BIGTABLE_USE_PLAINTEXT_NEGOTIATION - Static variable in class com.google.cloud.bigtable.hbase.BigtableOptionsFactory
Constant BIGTABLE_USE_PLAINTEXT_NEGOTIATION="google.bigtable.use.plaintext.negotiation"
BIGTABLE_USE_SERVICE_ACCOUNTS_DEFAULT - Static variable in class com.google.cloud.bigtable.hbase.BigtableOptionsFactory
Constant BIGTABLE_USE_SERVICE_ACCOUNTS_DEFAULT=true
BIGTABLE_USE_SERVICE_ACCOUNTS_KEY - Static variable in class com.google.cloud.bigtable.hbase.BigtableOptionsFactory
Key to set to enable service accounts to be used, either metadata server-based or P12-based.
BIGTABLE_USE_TIMEOUTS_KEY - Static variable in class com.google.cloud.bigtable.hbase.BigtableOptionsFactory
Should timeouts be used? Currently, this feature is experimental.
BIGTABLE_V2_INSTANCE_FMT - Static variable in class com.google.cloud.bigtable.grpc.BigtableInstanceName
Constant BIGTABLE_V2_INSTANCE_FMT="projects/%s/instances/%s"
BIGTABLE_WHILE_MATCH_RESULT_RESULT_SCAN_ADAPTER - Static variable in class com.google.cloud.bigtable.hbase.adapters.Adapters
Constant BIGTABLE_WHILE_MATCH_RESULT_RESULT_SCAN_ADAPTER
BigtableAdmin - Class in com.google.cloud.bigtable.hbase1_x
This is an hbase 1.x implementation of AbstractBigtableAdmin.
BigtableAdmin(CommonConnection) - Constructor for class com.google.cloud.bigtable.hbase1_x.BigtableAdmin
 
BigtableAdmin - Class in com.google.cloud.bigtable.hbase2_x
HBase 2.x specific implementation of AbstractBigtableAdmin.
BigtableAdmin(AbstractBigtableConnection) - Constructor for class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
 
BigtableAsyncAdmin - Class in com.google.cloud.bigtable.hbase2_x
Bigtable implementation of AsyncAdmin
BigtableAsyncAdmin(CommonConnection) - Constructor for class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
 
BigtableAsyncBufferedMutator - Class in com.google.cloud.bigtable.hbase2_x
Bigtable implementation of AsyncBufferedMutator
BigtableAsyncBufferedMutator(HBaseRequestAdapter, Configuration, BigtableSession) - Constructor for class com.google.cloud.bigtable.hbase2_x.BigtableAsyncBufferedMutator
Constructor for BigtableBufferedMutator.
BigtableAsyncConnection - Class in org.apache.hadoop.hbase.client
Bigtable implementation of AsyncConnection
BigtableAsyncConnection(Configuration) - Constructor for class org.apache.hadoop.hbase.client.BigtableAsyncConnection
 
BigtableAsyncConnection(Configuration, AsyncRegistry, String, User) - Constructor for class org.apache.hadoop.hbase.client.BigtableAsyncConnection
 
BigtableAsyncRegistry - Class in org.apache.hadoop.hbase.client
Bigtable implementation of AsyncRegistry.
BigtableAsyncRegistry(Configuration) - Constructor for class org.apache.hadoop.hbase.client.BigtableAsyncRegistry
 
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
 
BigtableAsyncTable - Class in com.google.cloud.bigtable.hbase2_x
Bigtable implementation of AsyncTable.
BigtableAsyncTable(CommonConnection, HBaseRequestAdapter) - Constructor for class com.google.cloud.bigtable.hbase2_x.BigtableAsyncTable
 
BigtableAsyncTableRegionLocator - Class in com.google.cloud.bigtable.hbase2_x
Bigtable implementation of AsyncTableRegionLocator
BigtableAsyncTableRegionLocator(TableName, BigtableOptions, IBigtableDataClient) - Constructor for class com.google.cloud.bigtable.hbase2_x.BigtableAsyncTableRegionLocator
 
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
 
BigtableBufferedMutator - Class in com.google.cloud.bigtable.hbase
Bigtable's BufferedMutator implementation.
BigtableBufferedMutator(HBaseRequestAdapter, Configuration, BigtableSession, BufferedMutator.ExceptionListener) - Constructor for class com.google.cloud.bigtable.hbase.BigtableBufferedMutator
Constructor for BigtableBufferedMutator.
BigtableBufferedMutatorHelper - Class in com.google.cloud.bigtable.hbase
A helper for Bigtable's BufferedMutator implementations.
BigtableBufferedMutatorHelper(HBaseRequestAdapter, Configuration, BigtableSession) - Constructor for class com.google.cloud.bigtable.hbase.BigtableBufferedMutatorHelper
Constructor for BigtableBufferedMutator.
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.
BigtableConfiguration - Class in com.google.cloud.bigtable.hbase
This class provides a simplified mechanism of creating a programmatic Bigtable Connection.
BigtableConfiguration() - Constructor for class com.google.cloud.bigtable.hbase.BigtableConfiguration
 
bigtableConnection - Variable in class com.google.cloud.bigtable.hbase.AbstractBigtableTable
 
BigtableConnection - Class in com.google.cloud.bigtable.hbase1_x
HBase 1.x specific implementation of AbstractBigtableConnection.
BigtableConnection(Configuration) - Constructor for class com.google.cloud.bigtable.hbase1_x.BigtableConnection
Constructor for BigtableConnection.
BigtableConnection - Class in com.google.cloud.bigtable.hbase2_x
HBase 2.x specific implementation of AbstractBigtableConnection.
BigtableConnection(Configuration) - Constructor for class com.google.cloud.bigtable.hbase2_x.BigtableConnection
Constructor for BigtableConnection.
BigtableConnection(Configuration, ExecutorService, User) - Constructor for class com.google.cloud.bigtable.hbase2_x.BigtableConnection
 
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.
BigtableExtendedScan - Class in com.google.cloud.bigtable.hbase
This is a Cloud Bigtable specific extension of Scan.
BigtableExtendedScan() - Constructor for class com.google.cloud.bigtable.hbase.BigtableExtendedScan
 
BigtableFilter - Class in com.google.cloud.bigtable.hbase.filter
An HBase Filter that wraps a Cloud Bigtable Filters.Filter.
BigtableFilter(Filters.Filter) - Constructor for class com.google.cloud.bigtable.hbase.filter.BigtableFilter
 
BigtableFilterAdapter - Class in com.google.cloud.bigtable.hbase.adapters.filters
Converts a BigtableFilter to a RowFilter.
BigtableFilterAdapter() - Constructor for class com.google.cloud.bigtable.hbase.adapters.filters.BigtableFilterAdapter
 
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.
bigtableInstanceName - Variable in class com.google.cloud.bigtable.hbase.adapters.admin.TableAdapter
 
bigtableInstanceName - Variable in class com.google.cloud.bigtable.hbase2_x.adapters.admin.TableAdapter2x
 
bigtableInstanceName - Variable in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
 
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.
BigtableOptionsFactory - Class in com.google.cloud.bigtable.hbase
Static methods to convert an instance of Configuration to a BigtableOptions instance.
BigtableOptionsFactory() - Constructor for class com.google.cloud.bigtable.hbase.BigtableOptionsFactory
 
BigtableRegionLocator - Class in com.google.cloud.bigtable.hbase
BigtableRegionLocator class.
BigtableRegionLocator(TableName, BigtableOptions, IBigtableDataClient) - Constructor for class com.google.cloud.bigtable.hbase.BigtableRegionLocator
Constructor for BigtableRegionLocator.
BigtableResultScannerAdapter<T> - Class in com.google.cloud.bigtable.hbase.adapters.read
Adapt a Bigtable ResultScanner to an HBase Result Scanner.
BigtableResultScannerAdapter(ResponseAdapter<T, Result>) - Constructor for class com.google.cloud.bigtable.hbase.adapters.read.BigtableResultScannerAdapter
Constructor for BigtableResultScannerAdapter.
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
 
BigtableTable - Class in com.google.cloud.bigtable.hbase2_x
 
BigtableTable(AbstractBigtableConnection, HBaseRequestAdapter) - Constructor for class com.google.cloud.bigtable.hbase2_x.BigtableTable
 
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
 
bigtableTableName - Variable in class com.google.cloud.bigtable.hbase.adapters.HBaseRequestAdapter
 
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
 
BigtableVersionInfo() - Constructor for class com.google.cloud.bigtable.config.BigtableVersionInfo
 
BigtableWhileMatchResultScannerAdapter - Class in com.google.cloud.bigtable.hbase.adapters.filters
Adapt a Bigtable ResultScanner to an HBase Result Scanner.
BigtableWhileMatchResultScannerAdapter(ResponseAdapter<FlatRow, Result>) - Constructor for class com.google.cloud.bigtable.hbase.adapters.filters.BigtableWhileMatchResultScannerAdapter
Constructor for BigtableWhileMatchResultScannerAdapter.
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
 
build() - Method in class com.google.cloud.bigtable.hbase.adapters.CheckAndMutateUtil.RequestBuilder
 
build() - Method in class com.google.cloud.bigtable.hbase.util.ModifyTableBuilder
 
buildAdapter() - Static method in class com.google.cloud.bigtable.hbase.adapters.filters.FilterAdapter
Create a new FilterAdapter
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.
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
 
buildFilter(Scan, ReadHooks) - Method in class com.google.cloud.bigtable.hbase.adapters.read.ScanAdapter
Given a Scan, build a Filters.Filter that include matching columns
buildGarbageCollectionRule(HColumnDescriptor) - Static method in class com.google.cloud.bigtable.hbase.adapters.admin.ColumnDescriptorAdapter
Construct an Bigtable GCRules.GCRule from the given column descriptor.
buildModifications(HTableDescriptor, HTableDescriptor) - Static method in class com.google.cloud.bigtable.hbase.util.ModifyTableBuilder
This method will build ModifyColumnFamiliesRequest objects based on a diff of the new and existing set of column descriptors.
buildResponse() - Method in class com.google.cloud.bigtable.grpc.async.MutateRowsRequestManager
 
BULK_OUTPUT_CONF_KEY - Static variable in class com.google.cloud.bigtable.mapreduce.Import
Constant BULK_OUTPUT_CONF_KEY="import.bulk.output"
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
Constructor for BulkMutation.
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 BulkMutationBatcher api.
BulkMutationGCJClient(BulkMutationBatcher) - 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, RequestContext) - 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
 
ByteStringer - Class in com.google.cloud.bigtable.hbase.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.
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.
catalogJanitorSwitch(boolean) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
 
catalogJanitorSwitch(boolean) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
 
Cell(String, ByteString, long, ByteString, List<String>) - Constructor for class com.google.cloud.bigtable.grpc.scanner.FlatRow.Cell
 
CellDeduplicationHelper - Class in com.google.cloud.bigtable.hbase.adapters
Helper class to deduplicate Cells in a mutation.
CellDeduplicationHelper() - Constructor for class com.google.cloud.bigtable.hbase.adapters.CellDeduplicationHelper
 
CellDeduplicationHelper.QualifierOnlyKey - Class in com.google.cloud.bigtable.hbase.adapters
 
cellValue(ByteString) - Method in class com.google.cloud.bigtable.grpc.scanner.FlatRowAdapter.FlatRowBuilder
CF_RENAME_PROP - Static variable in class com.google.cloud.bigtable.mapreduce.Import
Constant CF_RENAME_PROP="HBASE_IMPORTER_RENAME_CFS"
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.
checkAndDelete(byte[], byte[], byte[], byte[], Delete) - Method in class com.google.cloud.bigtable.hbase.AbstractBigtableTable
checkAndDelete(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], Delete) - Method in class com.google.cloud.bigtable.hbase.AbstractBigtableTable
checkAndDelete(byte[], byte[], byte[], CompareOperator, byte[], Delete) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableTable
checkAndMutate(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], RowMutations) - Method in class com.google.cloud.bigtable.hbase.AbstractBigtableTable
checkAndMutate(byte[], byte[]) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncTable
checkAndMutate(byte[], byte[], byte[], CompareOperator, byte[], RowMutations) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableTable
checkAndMutate(byte[], byte[]) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableTable
 
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.
CheckAndMutateUtil - Class in com.google.cloud.bigtable.hbase.adapters
 
CheckAndMutateUtil() - Constructor for class com.google.cloud.bigtable.hbase.adapters.CheckAndMutateUtil
 
CheckAndMutateUtil.RequestBuilder - Class in com.google.cloud.bigtable.hbase.adapters
This class can be used to convert HBase checkAnd* operations to Bigtable ConditionalRowMutations.
checkAndPut(byte[], byte[], byte[], byte[], Put) - Method in class com.google.cloud.bigtable.hbase.AbstractBigtableTable
checkAndPut(byte[], byte[], byte[], CompareFilter.CompareOp, byte[], Put) - Method in class com.google.cloud.bigtable.hbase.AbstractBigtableTable
checkAndPut(byte[], byte[], byte[], CompareOperator, byte[], Put) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableTable
CheckConfig - Class in com.google.cloud.bigtable.hbase
A simple utility class for checking and displaying common Bigtable-HBase configuration values.
CheckConfig() - Constructor for class com.google.cloud.bigtable.hbase.CheckConfig
 
cleanerChoreSwitch(boolean) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
 
cleanerChoreSwitch(boolean) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
 
clearBlockCache(TableName) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
 
clearBlockCache(TableName) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
 
clearCompactionQueues(ServerName, Set<String>) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
 
clearCompactionQueues(ServerName, Set<String>) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
 
clearDeadServers(List<ServerName>) - Method in class com.google.cloud.bigtable.hbase1_x.BigtableAdmin
 
clearDeadServers(List<ServerName>) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
 
clearDeadServers(List<ServerName>) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
 
clearRowInProgress() - Method in class com.google.cloud.bigtable.grpc.scanner.RowMerger
 
CLIENT_VERSION - Static variable in class com.google.cloud.bigtable.config.BigtableVersionInfo
 
clientWrapper - Variable in class com.google.cloud.bigtable.hbase.AbstractBigtableTable
 
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
 
cloneSnapshot(String, TableName, boolean) - Method in class com.google.cloud.bigtable.hbase1_x.BigtableAdmin
 
cloneSnapshot(String, TableName, boolean) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
 
cloneSnapshot(String, TableName) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
 
cloneSnapshot(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
This is needed for the hbase shell.
cloneSnapshot(byte[], TableName) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
 
cloneSnapshot(String, TableName) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
 
cloneSnapshotAsync(String, TableName) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
 
cloneTableSchema(TableName, TableName, boolean) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
 
cloneTableSchema(TableName, TableName, boolean) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
 
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 class com.google.cloud.bigtable.hbase.AbstractBigtableTable
close() - Method in interface com.google.cloud.bigtable.hbase.adapters.filters.FilterAdapterContext.ContextCloseable
 
close() - Method in class com.google.cloud.bigtable.hbase.BigtableBufferedMutator
close() - Method in class com.google.cloud.bigtable.hbase.BigtableBufferedMutatorHelper
 
close() - Method in class com.google.cloud.bigtable.hbase.BigtableRegionLocator
close() - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncBufferedMutator
close() - Method in interface com.google.cloud.bigtable.metrics.Timer.Context
 
close() - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
close() - Method in class org.apache.hadoop.hbase.client.AbstractBigtableConnection
close() - Method in class org.apache.hadoop.hbase.client.BigtableAsyncConnection
 
close() - Method in class org.apache.hadoop.hbase.client.BigtableAsyncRegistry
 
closeRegion(String, String) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
closeRegion(byte[], String) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
closeRegion(ServerName, HRegionInfo) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
closeRegionWithEncodedRegionName(String, String) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
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.
CloudBigtableService - Interface in com.google.cloud.bigtable.batch.common
This interface describes functionality required by CloudBigtableIO that send requests to Cloud Bigtable
CloudBigtableServiceImpl - Class in com.google.cloud.bigtable.batch.common
 
CloudBigtableServiceImpl() - Constructor for class com.google.cloud.bigtable.batch.common.CloudBigtableServiceImpl
 
collectUnsupportedStatuses(FilterAdapterContext, Filter, List<FilterSupportStatus>) - Method in class com.google.cloud.bigtable.hbase.adapters.filters.FilterAdapter
Recursively collect all unsupported filters contained in Filter (which may be a FilterList)
collectUnsupportedStatuses(FilterAdapterContext, FilterList, List<FilterSupportStatus>) - Method in class com.google.cloud.bigtable.hbase.adapters.filters.FilterListAdapter
Collect FilterSupportStatuses from the filter Filter and all subfilters.
collectUnsupportedStatuses(FilterAdapterContext, Filter, List<FilterSupportStatus>) - Method in class com.google.cloud.bigtable.hbase.adapters.filters.SingleFilterAdapter
Collect unsupported status objects into the given list.
collectUnsupportedStatuses(FilterAdapterContext, S, List<FilterSupportStatus>) - Method in interface com.google.cloud.bigtable.hbase.adapters.filters.UnsupportedStatusCollector
Collect FilterSupportStatuses from the filter Filter and all subfilters.
ColumnCountGetFilterAdapter - Class in com.google.cloud.bigtable.hbase.adapters.filters
Adapter for the ColumnCountGetFilter.
ColumnCountGetFilterAdapter() - Constructor for class com.google.cloud.bigtable.hbase.adapters.filters.ColumnCountGetFilterAdapter
 
ColumnDescriptorAdapter - Class in com.google.cloud.bigtable.hbase.adapters.admin
Adapt a single instance of an HBase HColumnDescriptor to an instance of ColumnFamily
ColumnDescriptorAdapter() - Constructor for class com.google.cloud.bigtable.hbase.adapters.admin.ColumnDescriptorAdapter
 
columnDescriptorAdapter - Static variable in class com.google.cloud.bigtable.hbase2_x.adapters.admin.TableAdapter2x
 
ColumnPaginationFilterAdapter - Class in com.google.cloud.bigtable.hbase.adapters.filters
Adapter to convert a ColumnPaginationFilter to a RowFilter.
ColumnPaginationFilterAdapter() - Constructor for class com.google.cloud.bigtable.hbase.adapters.filters.ColumnPaginationFilterAdapter
 
ColumnPrefixFilterAdapter - Class in com.google.cloud.bigtable.hbase.adapters.filters
Adapter for a single ColumnPrefixFilter to a Cloud Bigtable RowFilter.
ColumnPrefixFilterAdapter() - Constructor for class com.google.cloud.bigtable.hbase.adapters.filters.ColumnPrefixFilterAdapter
 
ColumnRangeFilterAdapter - Class in com.google.cloud.bigtable.hbase.adapters.filters
Adapter for a single ColumnRangeFilter to a Cloud Bigtable RowFilter.
ColumnRangeFilterAdapter() - Constructor for class com.google.cloud.bigtable.hbase.adapters.filters.ColumnRangeFilterAdapter
 
com.google.cloud.bigtable.batch.common - package com.google.cloud.bigtable.batch.common
Google Cloud Bigtable Utilities used by Dataflow.
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.hbase - package com.google.cloud.bigtable.hbase
 
com.google.cloud.bigtable.hbase.adapters - package com.google.cloud.bigtable.hbase.adapters
 
com.google.cloud.bigtable.hbase.adapters.admin - package com.google.cloud.bigtable.hbase.adapters.admin
 
com.google.cloud.bigtable.hbase.adapters.filters - package com.google.cloud.bigtable.hbase.adapters.filters
 
com.google.cloud.bigtable.hbase.adapters.read - package com.google.cloud.bigtable.hbase.adapters.read
 
com.google.cloud.bigtable.hbase.filter - package com.google.cloud.bigtable.hbase.filter
 
com.google.cloud.bigtable.hbase.util - package com.google.cloud.bigtable.hbase.util
 
com.google.cloud.bigtable.hbase1_x - package com.google.cloud.bigtable.hbase1_x
 
com.google.cloud.bigtable.hbase2_x - package com.google.cloud.bigtable.hbase2_x
 
com.google.cloud.bigtable.hbase2_x.adapters.admin - package com.google.cloud.bigtable.hbase2_x.adapters.admin
 
com.google.cloud.bigtable.mapreduce - package com.google.cloud.bigtable.mapreduce
 
com.google.cloud.bigtable.metrics - package com.google.cloud.bigtable.metrics
 
com.google.cloud.bigtable.test.emulator - package com.google.cloud.bigtable.test.emulator
 
com.google.cloud.bigtable.util - package com.google.cloud.bigtable.util
 
CommonConnection - Interface in org.apache.hadoop.hbase.client
Common interface for AbstractBigtableConnection and HBase 2's BigtableAsyncConnection.
compact(TableName, CompactType) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
 
compact(TableName, byte[], CompactType) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
 
compact(TableName, CompactType) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
 
compact(TableName, byte[], CompactType) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
 
compact(TableName) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
compact(TableName, byte[]) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
compactRegion(byte[]) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
 
compactRegion(byte[], byte[]) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
 
compactRegion(byte[]) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
compactRegion(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
compactRegionServer(ServerName) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
 
compactRegionServer(ServerName) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
 
compactRegionServer(ServerName, boolean) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
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
 
composePreSendHook(Function<Query, Query>) - Method in class com.google.cloud.bigtable.hbase.adapters.read.DefaultReadHooks
Add a Function that will modify the Query before it is sent to Cloud Bigtable.
composePreSendHook(Function<Query, Query>) - Method in interface com.google.cloud.bigtable.hbase.adapters.read.ReadHooks
Add a Function that will modify the Query before it is sent to Cloud Bigtable.
configure(String, String) - Static method in class com.google.cloud.bigtable.hbase.BigtableConfiguration
Create and configure a new Configuration.
configure(String, String, String) - Static method in class com.google.cloud.bigtable.hbase.BigtableConfiguration
Create and configure a new Configuration.
configure(Configuration, String, String) - Static method in class com.google.cloud.bigtable.hbase.BigtableConfiguration
Configure and return an existing Configuration.
configure(Configuration, String, String, String) - Static method in class com.google.cloud.bigtable.hbase.BigtableConfiguration
Configure and return an existing Configuration.
configureCfRenaming(Configuration, Map<String, String>) - Static method in class com.google.cloud.bigtable.mapreduce.Import
Sets a configuration property with key Import.CF_RENAME_PROP in conf that tells the mapper how to rename column families.
ConfiguredCallOptionsFactory(CallOptionsConfig) - Constructor for class com.google.cloud.bigtable.grpc.CallOptionsFactory.ConfiguredCallOptionsFactory
 
connect(String, String) - Static method in class com.google.cloud.bigtable.hbase.BigtableConfiguration
connect.
connect(String, String, String) - Static method in class com.google.cloud.bigtable.hbase.BigtableConfiguration
connect.
connect(Configuration) - Static method in class com.google.cloud.bigtable.hbase.BigtableConfiguration
connect.
connection - Variable in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
 
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
 
convertToResult(FlatRow) - Method in class com.google.cloud.bigtable.hbase.AbstractBigtableTable
 
convertToTableExistsException(TableName, Throwable) - Static method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
 
coprocessorService(byte[]) - Method in class com.google.cloud.bigtable.hbase.AbstractBigtableTable
coprocessorService(Class<T>, byte[], byte[], Batch.Call<T, R>) - Method in class com.google.cloud.bigtable.hbase.AbstractBigtableTable
coprocessorService(Class<T>, byte[], byte[], Batch.Call<T, R>, Batch.Callback<R>) - Method in class com.google.cloud.bigtable.hbase.AbstractBigtableTable
coprocessorService(Function<RpcChannel, S>, ServiceCaller<S, R>) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
 
coprocessorService(Function<RpcChannel, S>, ServiceCaller<S, R>, ServerName) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
 
coprocessorService(Function, ServiceCaller, byte[]) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncTable
coprocessorService(Function, ServiceCaller, AsyncTable.CoprocessorCallback) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncTable
coprocessorService() - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
coprocessorService(ServerName) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
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
 
createAdapter(TableName) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableConnection
 
createAdapter(TableName) - Method in class org.apache.hadoop.hbase.client.BigtableAsyncConnection
 
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
 
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() - Method in interface com.google.cloud.bigtable.core.IBigtableDataClient
Creates IBulkMutation batcher.
createBulkMutationBatcher() - Method in class com.google.cloud.bigtable.grpc.BigtableDataClientWrapper
Creates IBulkMutation batcher.
createBulkMutationBatcher() - Method in class com.google.cloud.bigtable.grpc.BigtableDataGCJClient
 
createBulkMutationWrapper(BigtableTableName) - Method in class com.google.cloud.bigtable.grpc.BigtableSession
createBulkMutationWrapper.
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
Create a new ChannelPool, with auth headers.
createChannelPool(ChannelPool.ChannelFactory, 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.
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
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.
createMutationsAdapter(PutAdapter) - Static method in class com.google.cloud.bigtable.hbase.adapters.Adapters
createMutationsAdapter.
createNamespace(NamespaceDescriptor) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
 
createNamespace(NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
createNamespaceAsync(NamespaceDescriptor) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
 
createNettyChannel(String, BigtableOptions, ClientInterceptor...) - Static method in class com.google.cloud.bigtable.grpc.BigtableSession
createNettyChannel.
createPutAdapter(Configuration, BigtableOptions) - Static method in class com.google.cloud.bigtable.hbase.adapters.Adapters
createPutAdapter.
createRegionLocation(byte[], byte[]) - Method in class com.google.cloud.bigtable.hbase.adapters.SampledRowKeysAdapter
HBase 1.x and 2.x have non compatible HRegionInfo classes.
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
 
createSampledRowKeysAdapter(TableName, ServerName) - Method in class com.google.cloud.bigtable.hbase1_x.BigtableConnection
 
createSampledRowKeysAdapter(TableName, ServerName) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableConnection
Due to hbase 1.x to 2.x binary incompatibilities.
createSampledRowKeysAdapter(TableName, ServerName) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableConnection
There are some hbase 1.x and 2.x incompatibilities which require this abstract method.
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
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.
createSplitKeys(byte[], byte[], int) - Static method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
 
createSubmittableJob(Configuration, String[]) - Static method in class com.google.cloud.bigtable.mapreduce.Export
Sets up the actual job.
createSubmittableJob(Configuration, String[]) - Static method in class com.google.cloud.bigtable.mapreduce.Import
Sets up the actual job.
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.
createTable(TableDescriptor) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
createTable(TableDescriptor, byte[], byte[], int) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
createTable(TableDescriptor, byte[][]) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
createTable(TableDescriptor, byte[][]) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
createTable(TableDescriptor, byte[], byte[], int) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
createTable(TableDescriptor) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
 
createTable(HTableDescriptor) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
createTable(HTableDescriptor, byte[], byte[], int) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
createTable(HTableDescriptor, byte[][]) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
createTable(TableName, CreateTableRequest) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
Creates a 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.
createTableAsync(TableDescriptor, byte[][]) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
createTableAsync(HTableDescriptor, byte[][]) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
createTableAsync(TableName, CreateTableRequest) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
 
createTableFromSnapshotAsync(CreateTableFromSnapshotRequest) - Method in interface com.google.cloud.bigtable.core.IBigtableTableAdminClient
Creates a new table from a snapshot.
createTableFromSnapshotAsync(CreateTableFromSnapshotRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableTableAdminClient
Creates a new table from a snapshot.
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
Creates a new table from a snapshot.
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.
CUSTOM_USER_AGENT_KEY - Static variable in class com.google.cloud.bigtable.hbase.BigtableOptionsFactory
Constant CUSTOM_USER_AGENT_KEY="google.bigtable.custom.user.agent"

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
 
decommissionRegionServers(List<ServerName>, boolean) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
 
decommissionRegionServers(List<ServerName>, boolean) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
 
deduplicateFamily(Mutation, byte[]) - Static method in class com.google.cloud.bigtable.hbase.adapters.CellDeduplicationHelper
Given a Mutation and a family with potentially duplicate cell family:qualifier combinations, remove all entries except for the last for that family:qualifier pair.
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
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.
DefaultReadHooks - Class in com.google.cloud.bigtable.hbase.adapters.read
Default implementation of ReadHooks.
DefaultReadHooks() - Constructor for class com.google.cloud.bigtable.hbase.adapters.read.DefaultReadHooks
 
delegate - Variable in class com.google.cloud.bigtable.hbase.adapters.read.ReaderExpressionHelper.QuoteFilterExpressionStream
 
delegate - Variable in class com.google.cloud.bigtable.hbase.adapters.read.ReaderExpressionHelper.QuoteMetaOutputStream
 
delete(Delete) - Method in class com.google.cloud.bigtable.hbase.AbstractBigtableTable
delete(List<Delete>) - Method in class com.google.cloud.bigtable.hbase.AbstractBigtableTable
delete(String) - Method in class com.google.cloud.bigtable.hbase.util.ModifyTableBuilder
 
delete(Delete) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncTable
delete(List<Delete>) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncTable
DELETE_ADAPTER - Static variable in class com.google.cloud.bigtable.hbase.adapters.Adapters
Constant DELETE_ADAPTER
DeleteAdapter - Class in com.google.cloud.bigtable.hbase.adapters
Adapt a single Delete operation to a Google Cloud Java MutationApi.
DeleteAdapter() - Constructor for class com.google.cloud.bigtable.hbase.adapters.DeleteAdapter
 
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.
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.
deleteColumn(TableName, byte[]) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
deleteColumn(String, byte[]) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
Deprecated.
deleteColumn(String, String) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
Deprecated.
deleteColumnFamily(TableName, byte[]) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
 
deleteColumnFamily(TableName, byte[]) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
 
deleteColumnFamilyAsync(TableName, byte[]) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
 
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.
deleteNamespace(String) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
 
deleteNamespace(String) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
deleteNamespaceAsync(String) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
deleteRowRangeByPrefix(TableName, byte[]) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
deleteRowRangeByPrefix.
deleteSnapshot(String) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
 
deleteSnapshot(byte[]) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
deleteSnapshot(String) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
deleteSnapshotAsync(DeleteSnapshotRequest) - Method in interface com.google.cloud.bigtable.core.IBigtableTableAdminClient
Permanently deletes the specified snapshot.
deleteSnapshotAsync(DeleteSnapshotRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableTableAdminClient
Permanently deletes the specified snapshot.
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
Permanently deletes the specified snapshot.
deleteSnapshots() - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
 
deleteSnapshots(Pattern) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
 
deleteSnapshots(String) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
deleteSnapshots(Pattern) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
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.
deleteTable(TableName) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
deleteTable(TableName) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
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.
deleteTableAsync(TableName) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
 
deleteTableAsyncInternal(TableName) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
 
deleteTables(String) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
deleteTables(Pattern) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
deleteTableSnapshots(Pattern, Pattern) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
 
deleteTableSnapshots(Pattern) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
 
deleteTableSnapshots(String, String) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
deleteTableSnapshots(Pattern, Pattern) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
DIRECT_EXECUTOR - Static variable in class com.google.cloud.bigtable.hbase2_x.FutureUtils
 
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).
disableReplicationPeer(String) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
 
disableReplicationPeer(String) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
 
disableReplicationPeerAsync(String) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
 
disableTable(TableName) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
 
disableTable(TableName) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
disableTable(String) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
Deprecated.
disableTableAsync(TableName) - Method in class com.google.cloud.bigtable.hbase1_x.BigtableAdmin
disableTableAsync(TableName) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
disableTableReplication(TableName) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
 
disableTableReplication(TableName) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
 
disableTables(String) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
disableTables(Pattern) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
Driver - Class in com.google.cloud.bigtable.mapreduce
Driver for bigtable mapreduce jobs.
Driver() - Constructor for class com.google.cloud.bigtable.mapreduce.Driver
 
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(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, String) - 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(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, String) - 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

ENABLE_GRPC_RETRIES_KEY - Static variable in class com.google.cloud.bigtable.hbase.BigtableOptionsFactory
Key to set to a boolean flag indicating whether or not grpc retries should be enabled.
ENABLE_GRPC_RETRY_DEADLINEEXCEEDED_KEY - Static variable in class com.google.cloud.bigtable.hbase.BigtableOptionsFactory
Key to set to a boolean flag indicating whether or not to retry grpc call on deadline exceeded.
enableBulkMutationThrottling() - Method in class com.google.cloud.bigtable.config.BulkOptions.Builder
Enable an experimental feature that will throttle requests from BulkMutation if request latency surpasses a latency threshold.
enableCatalogJanitor(boolean) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
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
 
enableReplicationPeer(String) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
 
enableReplicationPeer(String) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
 
enableReplicationPeerAsync(String) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
 
enableRetries() - Method in class com.google.cloud.bigtable.config.RetryOptions
Enable or disable retries.
enableTable(TableName) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
enableTable(TableName) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
enableTable(String) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
Deprecated.
enableTableAsync(TableName) - Method in class com.google.cloud.bigtable.hbase1_x.BigtableAdmin
enableTableAsync(TableName) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
enableTableReplication(TableName) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
 
enableTableReplication(TableName) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
 
enableTables(String) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
enableTables(Pattern) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
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
 
equals(Object) - Method in class com.google.cloud.bigtable.hbase.adapters.CellDeduplicationHelper.QualifierOnlyKey
 
equals(Object) - Method in class com.google.cloud.bigtable.hbase.adapters.read.RowCell
Needed doing 'contains' on List.
equals(Object) - Method in class com.google.cloud.bigtable.hbase.filter.BigtableFilter
 
equals(Object) - Method in class com.google.cloud.bigtable.hbase.filter.TimestampRangeFilter
 
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
execProcedure(String, String, Map<String, String>) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
 
execProcedure(String, String, Map<String, String>) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
execProcedureWithRet(String, String, Map<String, String>) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
execProcedureWithReturn(String, String, Map<String, String>) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
 
execProcedureWithReturn(String, String, Map<String, String>) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
 
execute() - Method in class com.google.cloud.bigtable.test.emulator.Start
 
execute() - Method in class com.google.cloud.bigtable.test.emulator.Stop
 
exists(Get) - Method in class com.google.cloud.bigtable.hbase.AbstractBigtableTable
exists(List<Get>) - Method in class com.google.cloud.bigtable.hbase.BatchExecutor
Implementation of Table.existsAll(List).
exists(Get) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncTable
exists(List<Get>) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncTable
exists(List<Get>) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableTable
existsAll(List<Get>) - Method in class com.google.cloud.bigtable.hbase.AbstractBigtableTable
Export - Class in com.google.cloud.bigtable.mapreduce
Export an HBase table.
Export() - Constructor for class com.google.cloud.bigtable.mapreduce.Export
 
extract(ByteString) - Static method in class com.google.cloud.bigtable.hbase.util.ByteStringer
 
extractIdentifier(Metadata) - Static method in class com.google.cloud.bigtable.grpc.io.ChannelPool
 
extractRegexPattern(RegexStringComparator) - Static method in class com.google.cloud.bigtable.hbase.adapters.filters.FilterAdapterHelper
Extract a regular expression from a RegexStringComparator.

F

failedCount - Variable in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation