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 aBigtableAsyncRpc
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 ofColumnFamily.Builder
. - adapt(ColumnFamily) - Method in class com.google.cloud.bigtable.hbase.adapters.admin.ColumnDescriptorAdapter
-
Convert a Bigtable
ColumnFamily
to an HBaseHColumnDescriptor
. - 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 JavaMutationApi
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 JavaMutationApi
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 JavaMutationApi
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 JavaMutationApi
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 JavaMutationApi
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 JavaMutationApi
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
- 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 theMutateRowsRequest.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 theResponseQueueReader.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
-
Implementation of
HTable.batchCallback(List, Object[], Batch.Callback)
- 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
-
Deprecated.Please use
BigtableOptionsFactory.BIGTABLE_MUTATE_RPC_TIMEOUT_MS_KEY
orBigtableOptionsFactory.BIGTABLE_READ_RPC_TIMEOUT_MS_KEY
based on long operation. - 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 wrapsBigtableDataClient
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'sBigtableDataClient
. - 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 BigtableFilters.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 aRowFilter
. - 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 aBigtableOptions
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
BigtableSession
s. - 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 wrapsBigtableTableAdminClient
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'sBigtableTableAdminClient
&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 aBigtableDataSettings
orBigtableTableAdminSettings
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 aFilters.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
MutateRowRequest
s into a singleMutateRowsRequest
. - 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'sBulkMutationBatcher
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
ReadRowsRequest
s with a single row key into a singleReadRowsRequest
with aRowSet
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
ByteString
s. - 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 implementsClientCallStreamObserver
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.Please use
CallOptionsConfig.builder()
- CallOptionsConfig.Builder - Class in com.google.cloud.bigtable.config
- CallOptionsFactory - Interface in com.google.cloud.bigtable.grpc
-
A factory that creates
CallOptions
for use inBigtableDataClient
RPCs. - CallOptionsFactory.ConfiguredCallOptionsFactory - Class in com.google.cloud.bigtable.grpc
-
Creates a new
CallOptions
based on aCallOptionsConfig
. - CallOptionsFactory.Default - Class in com.google.cloud.bigtable.grpc
-
Returns
CallOptions.DEFAULT
with anyContext.current()
'sContext.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
ConditionalRowMutation
s. - 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 ofColumnFamily
- 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 theQuery
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 theQuery
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 MetricsCounter
. - 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 onDeadline
. - 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
fromBigtableOptions
. - 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
-
Create a
BigtableInstanceClient
. - 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 anSlf4jReporter
. - 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
fromBigtableOptions
. - 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 usingCallController.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 MetricsMetricRegistry
. - 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
- failedFuture(Throwable) - Static method in class com.google.cloud.bigtable.hbase2_x.FutureUtils
- FamilyFilterAdapter - Class in com.google.cloud.bigtable.hbase.adapters.filters
-
Adapter for a single
FamilyFilter
to a Cloud Bigtable RowFilter. - FamilyFilterAdapter() - Constructor for class com.google.cloud.bigtable.hbase.adapters.filters.FamilyFilterAdapter
- fatal(String, Object...) - Method in class com.google.cloud.bigtable.config.Logger
-
fatal
- fatal(String, Throwable, Object...) - Method in class com.google.cloud.bigtable.config.Logger
-
fatal
- FILTER_ADAPTER - Static variable in class com.google.cloud.bigtable.hbase.adapters.Adapters
-
Constant
FILTER_ADAPTER
- FILTER_ARGS_CONF_KEY - Static variable in class com.google.cloud.bigtable.mapreduce.Import
-
Constant
FILTER_ARGS_CONF_KEY="import.filter.args"
- FILTER_CLASS_CONF_KEY - Static variable in class com.google.cloud.bigtable.mapreduce.Import
-
Constant
FILTER_CLASS_CONF_KEY="import.filter.class"
- FilterAdapter - Class in com.google.cloud.bigtable.hbase.adapters.filters
-
An adapter for converting an HBase Filter into Bigtable RowFilter objects
- FilterAdapter() - Constructor for class com.google.cloud.bigtable.hbase.adapters.filters.FilterAdapter
-
Building the adapter map properly requires using a reference to the main FilterAdapter (to pass to FilterListAdapter).
- FilterAdapterContext - Class in com.google.cloud.bigtable.hbase.adapters.filters
-
Context for the currently executing filter adapter.
- FilterAdapterContext(Scan, ReadHooks) - Constructor for class com.google.cloud.bigtable.hbase.adapters.filters.FilterAdapterContext
-
Constructor for FilterAdapterContext.
- FilterAdapterContext.ContextCloseable - Interface in com.google.cloud.bigtable.hbase.adapters.filters
- FilterAdapterHelper - Class in com.google.cloud.bigtable.hbase.adapters.filters
-
Helpers for filter adapters.
- FilterAdapterHelper() - Constructor for class com.google.cloud.bigtable.hbase.adapters.filters.FilterAdapterHelper
- filterKeyValue(Cell) - Method in class com.google.cloud.bigtable.hbase.filter.BigtableFilter
- filterKeyValue(Cell) - Method in class com.google.cloud.bigtable.hbase.filter.TimestampRangeFilter
-
This is for HBase compatibility, and will not be used for Cloud Bigtable
- filterKv(Filter, Cell) - Static method in class com.google.cloud.bigtable.mapreduce.Import
-
Attempt to filter out the keyvalue
- FilterListAdapter - Class in com.google.cloud.bigtable.hbase.adapters.filters
-
Adapts a FilterList into either a RowFilter with chaining or interleaving.
- FilterListAdapter(FilterAdapter) - Constructor for class com.google.cloud.bigtable.hbase.adapters.filters.FilterListAdapter
-
Constructor for FilterListAdapter.
- FilterSupportStatus - Class in com.google.cloud.bigtable.hbase.adapters.filters
-
FilterSupportStatus is a result type indicating whether a filter has a supported adaptation to bigtable reader expressions.
- finalizeStats(Status) - Method in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation
- finalizeStats(Status) - Method in class com.google.cloud.bigtable.grpc.scanner.RetryingReadRowsOperation
- finishCell() - Method in class com.google.cloud.bigtable.grpc.scanner.FlatRowAdapter.FlatRowBuilder
-
Adds a Cell to
FlatRow.Cell
's map which is ordered by family. - finishRow() - Method in class com.google.cloud.bigtable.grpc.scanner.FlatRowAdapter.FlatRowBuilder
-
This method flattens the
FlatRowAdapter.FlatRowBuilder.cells
which has a map of Lists keyed by family name. - FirstKeyOnlyFilterAdapter - Class in com.google.cloud.bigtable.hbase.adapters.filters
-
Adapter for FirstKeyOnlyFilter to RowFilter.
- FirstKeyOnlyFilterAdapter() - Constructor for class com.google.cloud.bigtable.hbase.adapters.filters.FirstKeyOnlyFilterAdapter
- FLAT_ROW_ADAPTER - Static variable in class com.google.cloud.bigtable.hbase.adapters.Adapters
-
Constant
FLAT_ROW_ADAPTER
- FlatRow - Class in com.google.cloud.bigtable.grpc.scanner
-
This class stores represents a single row.
- FlatRow(ByteString, ImmutableList<FlatRow.Cell>) - Constructor for class com.google.cloud.bigtable.grpc.scanner.FlatRow
- FlatRow.Builder - Class in com.google.cloud.bigtable.grpc.scanner
- FlatRow.Cell - Class in com.google.cloud.bigtable.grpc.scanner
- FlatRow.Cell.Builder - Class in com.google.cloud.bigtable.grpc.scanner
- FlatRowAdapter - Class in com.google.cloud.bigtable.grpc.scanner
-
Adapter for
RowAdapter
that usesFlatRow
's to represent logical rows. - FlatRowAdapter() - Constructor for class com.google.cloud.bigtable.grpc.scanner.FlatRowAdapter
- FlatRowAdapter - Class in com.google.cloud.bigtable.hbase.adapters.read
- FlatRowAdapter() - Constructor for class com.google.cloud.bigtable.hbase.adapters.read.FlatRowAdapter
- FlatRowAdapter.FlatRowBuilder - Class in com.google.cloud.bigtable.grpc.scanner
- FlatRowBuilder() - Constructor for class com.google.cloud.bigtable.grpc.scanner.FlatRowAdapter.FlatRowBuilder
- FlatRowConverter - Class in com.google.cloud.bigtable.grpc.scanner
-
This class converts between instances of
FlatRow
andRow
. - FlatRowConverter() - Constructor for class com.google.cloud.bigtable.grpc.scanner.FlatRowConverter
- flush() - Method in interface com.google.cloud.bigtable.core.IBulkMutation
-
Sends any outstanding
RowMutation
and wait until all requests are complete. - flush() - Method in class com.google.cloud.bigtable.grpc.async.BulkMutation
-
Send any outstanding
MutateRowRequest
s and wait until all requests are complete. - flush() - Method in class com.google.cloud.bigtable.grpc.async.BulkMutationGCJClient
-
Sends any outstanding
RowMutation
and wait until all requests are complete. - flush() - Method in class com.google.cloud.bigtable.grpc.async.BulkMutationWrapper
-
Sends any outstanding
RowMutation
and wait until all requests are complete. - flush() - Method in class com.google.cloud.bigtable.grpc.async.BulkRead
-
Sends all remaining requests to the server.
- flush() - Method in class com.google.cloud.bigtable.hbase.BigtableBufferedMutator
- flush() - Method in class com.google.cloud.bigtable.hbase.BigtableBufferedMutatorHelper
- flush(TableName) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- flush() - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncBufferedMutator
- flush(TableName) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- flushRegion(byte[]) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- flushRegion(byte[]) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- flushRegionServer(ServerName) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- flushRegionServer(ServerName) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- forAllInstances(String) - Static method in class com.google.cloud.bigtable.grpc.BigtableClusterUtilities
-
Creates a
BigtableClusterUtilities
for all instances in a projectId. - forInstance(String, String) - Static method in class com.google.cloud.bigtable.grpc.BigtableClusterUtilities
-
Creates a
BigtableClusterUtilities
for a projectId and an instanceId. - fromConfiguration(Configuration) - Static method in class com.google.cloud.bigtable.hbase.BigtableOptionsFactory
-
fromConfiguration.
- FutureUtils - Class in com.google.cloud.bigtable.hbase2_x
-
Utility methods for converting guava
ListenableFuture
Future toCompletableFuture
. - FutureUtils() - Constructor for class com.google.cloud.bigtable.hbase2_x.FutureUtils
- FuzzyRowFilterAdapter - Class in com.google.cloud.bigtable.hbase.adapters.filters
-
An adapter for
FuzzyRowFilter
. - FuzzyRowFilterAdapter() - Constructor for class com.google.cloud.bigtable.hbase.adapters.filters.FuzzyRowFilterAdapter
G
- get(List<Get>) - Method in class com.google.cloud.bigtable.hbase.AbstractBigtableTable
- get(Get) - Method in class com.google.cloud.bigtable.hbase.AbstractBigtableTable
- get(ByteString) - Static method in class com.google.cloud.bigtable.hbase.util.ZeroCopyByteStringUtil
-
Extracts the byte array from the given
ByteString
without copy. - get(Get) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncTable
- get(List<Get>) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncTable
- GET_ADAPTER - Static variable in class com.google.cloud.bigtable.hbase.adapters.Adapters
-
Constant
GET_ADAPTER
- getAbsoluteMaxInFlightRpcs() - Method in class com.google.cloud.bigtable.grpc.async.ResourceLimiter
-
Getter for the field
maxInFlightRpcs
. - GetAdapter - Class in com.google.cloud.bigtable.hbase.adapters.read
-
A
Get
adapter that transform the Get into aQuery
using the proto-based filter language. - GetAdapter(ScanAdapter) - Constructor for class com.google.cloud.bigtable.hbase.adapters.read.GetAdapter
-
Constructor for GetAdapter.
- getAdapterForFilterOrThrow(Filter) - Method in class com.google.cloud.bigtable.hbase.adapters.filters.FilterAdapter
-
Get the adapter for the given Filter or throw an UnsupportedFilterException if one is not available.
- getAdmin() - Method in class com.google.cloud.bigtable.hbase1_x.BigtableConnection
- getAdmin() - Method in class com.google.cloud.bigtable.hbase2_x.BigtableConnection
- getAdmin() - Method in class org.apache.hadoop.hbase.client.AbstractBigtableConnection
- getAdminBuilder() - Method in class org.apache.hadoop.hbase.client.BigtableAsyncConnection
- getAdminBuilder(ExecutorService) - Method in class org.apache.hadoop.hbase.client.BigtableAsyncConnection
- getAdminHost() - Method in class com.google.cloud.bigtable.config.BigtableOptions
-
Getter for the field
tableAdminHost
. - getAllRegionInfos(TableName) - Method in class com.google.cloud.bigtable.hbase1_x.BigtableConnection
- getAllRegionInfos(TableName) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableConnection
- getAllRegionInfos(TableName) - Method in class org.apache.hadoop.hbase.client.BigtableAsyncConnection
- getAllRegionInfos(TableName) - Method in interface org.apache.hadoop.hbase.client.CommonConnection
-
Retrieve a region information on a table.
- getAllRegionLocations() - Method in class com.google.cloud.bigtable.hbase.BigtableRegionLocator
- getAlterStatus(TableName) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- getAlterStatus(byte[]) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- getAlterStatus(String) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
-
getAlterStatus.
- getApplicationDefaultCredential() - Static method in class com.google.cloud.bigtable.config.CredentialFactory
-
Initializes OAuth2 application default credentials based on the environment the code is running in.
- getAppProfile(GetAppProfileRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableInstanceClient
-
Get an application profile.
- getAppProfile(GetAppProfileRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableInstanceGrpcClient
-
Get an application profile.
- getAppProfileId() - Method in class com.google.cloud.bigtable.config.BigtableOptions
-
Getter for the field
appProfileId
. - getAsyncMutatorCount() - Method in class com.google.cloud.bigtable.config.BulkOptions
-
Getter for the field
asyncMutatorCount
. - getAsyncResult() - Method in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation
-
Initial execution of the RPC.
- getAutoflushMs() - Method in class com.google.cloud.bigtable.config.BulkOptions
-
Getter for the field
autoflushMs
. - getBackoffMultiplier() - Method in class com.google.cloud.bigtable.config.RetryOptions
-
Multiplier we will apply to backoff times between retries.
- getBatchExecutor() - Method in class com.google.cloud.bigtable.hbase.AbstractBigtableTable
-
Getter for the field
batchExecutor
. - getBatchExecutor() - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncTable
- getBatchSizes() - Method in class com.google.cloud.bigtable.grpc.async.BulkRead
- getBatchThreadPool() - Method in class com.google.cloud.bigtable.grpc.BigtableSessionSharedThreadPools
-
Getter for the field
batchThreadPool
. - getBigtableTableName() - Method in class com.google.cloud.bigtable.hbase.adapters.HBaseRequestAdapter
-
Getter for the field
bigtableTableName
. - getBlockingResult() - Method in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation
- getBufferedMutator(BufferedMutatorParams) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableConnection
- getBufferedMutator(TableName) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableConnection
- getBufferedMutatorBuilder(TableName) - Method in class org.apache.hadoop.hbase.client.BigtableAsyncConnection
- getBufferedMutatorBuilder(TableName, ExecutorService) - Method in class org.apache.hadoop.hbase.client.BigtableAsyncConnection
- getBulkMaxRequestSize() - Method in class com.google.cloud.bigtable.config.BulkOptions
-
Getter for the field
bulkMaxRequestSize
. - getBulkMaxRowKeyCount() - Method in class com.google.cloud.bigtable.config.BulkOptions
-
Getter for the field
bulkMaxRowKeyCount
. - getBulkMutationRpcTargetMs() - Method in class com.google.cloud.bigtable.config.BulkOptions
-
if
BulkOptions.isEnableBulkMutationThrottling()
, then bulk mutation RPC latency will be compared against this value. - getBulkOptions() - Method in class com.google.cloud.bigtable.config.BigtableOptions
-
Getter for the field
bulkOptions
. - getBytes(ByteString) - Static method in class com.google.cloud.bigtable.hbase.adapters.MutationAdapter
- getCachedCredentials() - Method in class com.google.cloud.bigtable.config.CredentialOptions.JsonCredentialsOptions
- getCallOptionsConfig() - Method in class com.google.cloud.bigtable.config.BigtableOptions
-
Getter for the field
callOptionsConfig
. - getCells() - Method in class com.google.cloud.bigtable.grpc.scanner.FlatRow
- getChannelCount() - Method in class com.google.cloud.bigtable.config.BigtableOptions
-
The number of data channels to create.
- getCluster(String, String) - Method in class com.google.cloud.bigtable.grpc.BigtableClusterUtilities
-
Gets the current configuration of the cluster as encapsulated by a
Cluster
object. - getCluster(GetClusterRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableInstanceClient
-
Gets information about a cluster.
- getCluster(GetClusterRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableInstanceGrpcClient
-
Gets information about a cluster.
- getClusterId() - Method in class com.google.cloud.bigtable.grpc.BigtableClusterName
- getClusterId() - Method in class com.google.cloud.bigtable.grpc.BigtableSnapshotName
- getClusterId() - Method in class org.apache.hadoop.hbase.client.BigtableAsyncRegistry
-
A non null return value is required for successful creation of asyncConnection.
- getClusterMetrics(EnumSet<ClusterMetrics.Option>) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- getClusterMetrics() - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- getClusterMetrics(EnumSet<ClusterMetrics.Option>) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- getClusterName() - Method in class com.google.cloud.bigtable.grpc.BigtableClusterName
- getClusterName() - Method in class com.google.cloud.bigtable.grpc.BigtableSession
-
Snapshot operations need various aspects of a
BigtableClusterName
. - getClusterName() - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- getClusterNodeCount(String, String) - Method in class com.google.cloud.bigtable.grpc.BigtableClusterUtilities
-
Gets the current number of nodes allocated to the cluster.
- getClusters() - Method in class com.google.cloud.bigtable.grpc.BigtableClusterUtilities
-
Gets a
ListClustersResponse
that contains all of the clusters for the projectId/instanceId configuration. - getClusterSize(String, String) - Method in class com.google.cloud.bigtable.grpc.BigtableClusterUtilities
-
Deprecated.Use
BigtableClusterUtilities.getCluster(String, String)
orBigtableClusterUtilities.getSingleCluster()
and then callCluster.getServeNodes()
. - getClusterSize() - Method in class com.google.cloud.bigtable.grpc.BigtableClusterUtilities
-
Gets the serve node count of an instance with a single cluster.
- getClusterStatus() - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- getCompactionState(TableName) - Method in class com.google.cloud.bigtable.hbase1_x.BigtableAdmin
- getCompactionState(TableName) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- getCompactionState(TableName, CompactType) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- getCompactionState(TableName) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- getCompactionState(TableName, CompactType) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- getCompactionStateForRegion(byte[]) - Method in class com.google.cloud.bigtable.hbase1_x.BigtableAdmin
- getCompactionStateForRegion(byte[]) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- getCompactionStateForRegion(byte[]) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- getConfiguration() - Method in class com.google.cloud.bigtable.hbase.AbstractBigtableTable
- getConfiguration() - Method in class com.google.cloud.bigtable.hbase.BigtableBufferedMutator
- getConfiguration() - Method in class com.google.cloud.bigtable.hbase.BigtableBufferedMutatorHelper
- getConfiguration() - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncBufferedMutator
- getConfiguration() - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncTable
- getConfiguration() - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- getConfiguration() - Method in class org.apache.hadoop.hbase.client.AbstractBigtableConnection
-
Returns the
Configuration
object used by this instance. - getConfiguration() - Method in class org.apache.hadoop.hbase.client.BigtableAsyncConnection
- getConfiguration() - Method in interface org.apache.hadoop.hbase.client.CommonConnection
-
Returns the
Configuration
object used by this instance. - getConnection() - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- getConnectionClass() - Static method in class com.google.cloud.bigtable.hbase.BigtableConfiguration
- getCredential() - Method in class com.google.cloud.bigtable.config.CredentialOptions.UserSuppliedCredentialOptions
- getCredentialFromPrivateKeyServiceAccount(String, String) - Static method in class com.google.cloud.bigtable.config.CredentialFactory
-
Initializes OAuth2 credential from a private keyfile, as described in Service accounts.
- getCredentialFromPrivateKeyServiceAccount(String, String, List<String>) - Static method in class com.google.cloud.bigtable.config.CredentialFactory
-
Initializes OAuth2 credential from a private keyfile, as described in Service accounts.
- getCredentialOptions() - Method in class com.google.cloud.bigtable.config.BigtableOptions
-
Get the credential this object was constructed with.
- getCredentials(CredentialOptions) - Static method in class com.google.cloud.bigtable.config.CredentialFactory
-
Look up a Credentials object based on a configuration of credentials described in a
CredentialOptions
. - getCredentialsInterceptor(CredentialOptions, RetryOptions) - Method in class com.google.cloud.bigtable.grpc.io.CredentialInterceptorCache
-
Given
CredentialOptions
that define how to look up credentials, do the following: Look up the credentials If there are credentials, create a gRPC interceptor that gets OAuth2 security tokens and add that token as a header on all calls. - getCredentialType() - Method in class com.google.cloud.bigtable.config.CredentialOptions
-
Getter for the field
credentialType
. - getCumulativeThrottlingTimeNanos() - Method in class com.google.cloud.bigtable.grpc.async.ResourceLimiterStats
- getCurrentFilterList() - Method in class com.google.cloud.bigtable.hbase.adapters.filters.FilterAdapterContext
-
getCurrentFilterList.
- getCurrentInFlightMaxRpcs() - Method in class com.google.cloud.bigtable.grpc.async.ResourceLimiter
-
Getter for the field
currentInFlightMaxRpcs
. - getCurrentNrHRS() - Method in class org.apache.hadoop.hbase.client.BigtableAsyncRegistry
- getDataChannelCount() - Method in class com.google.cloud.bigtable.config.BigtableOptions.Builder
- getDataClient() - Method in class com.google.cloud.bigtable.grpc.BigtableSession
-
Getter for the field
dataClient
. - getDataClientWrapper() - Method in class com.google.cloud.bigtable.grpc.BigtableSession
-
Getter for the field
clientWrapper
. - getDataHost() - Method in class com.google.cloud.bigtable.config.BigtableOptions
-
Getter for the field
dataHost
. - getDefaultOptions() - Static method in class com.google.cloud.bigtable.config.BigtableOptions
- getDefaultOptions() - Static method in class com.google.cloud.bigtable.config.RetryOptions
- getDescriptor(TableName) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- getDescriptor(TableName) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- getDescriptor() - Method in class com.google.cloud.bigtable.hbase2_x.BigtableTable
- getDisabledTables() - Method in class org.apache.hadoop.hbase.client.AbstractBigtableConnection
-
Getter for the field
disabledTables
. - getDisabledTables() - Method in class org.apache.hadoop.hbase.client.BigtableAsyncConnection
- getDisabledTables() - Method in interface org.apache.hadoop.hbase.client.CommonConnection
-
Getter for the field
disabledTables
. - getEndKeys() - Method in class com.google.cloud.bigtable.hbase.BigtableRegionLocator
- getEndTimestampExclusive() - Method in class com.google.cloud.bigtable.hbase.filter.TimestampRangeFilter
- getEnvJsonFile() - Static method in class com.google.cloud.bigtable.config.CredentialOptions
-
Get a configured json credentials file from the GOOGLE_APPLICATION_CREDENTIALS environment variable.
- getExhaustedRetriesException(Status) - Method in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation
- getFamily() - Method in class com.google.cloud.bigtable.grpc.scanner.FlatRow.Cell
- getFamily() - Method in class com.google.cloud.bigtable.hbase.adapters.read.RowCell
-
Deprecated.
- getFamilyArray() - Method in class com.google.cloud.bigtable.hbase.adapters.read.RowCell
- getFamilyLength() - Method in class com.google.cloud.bigtable.hbase.adapters.read.RowCell
- getFamilyOffset() - Method in class com.google.cloud.bigtable.hbase.adapters.read.RowCell
- getFilter() - Method in class com.google.cloud.bigtable.hbase.filter.BigtableFilter
- getFilterListDepth() - Method in class com.google.cloud.bigtable.hbase.adapters.filters.FilterAdapterContext
-
getFilterListDepth.
- getFilterSupportStatuses() - Method in exception com.google.cloud.bigtable.hbase.adapters.filters.UnsupportedFilterException
-
The failed FilterSupportStatus instances containing reason messages.
- getHbck(ServerName) - Method in class org.apache.hadoop.hbase.client.BigtableAsyncConnection
- getHbck() - Method in class org.apache.hadoop.hbase.client.BigtableAsyncConnection
- getHeapSize() - Method in class com.google.cloud.bigtable.grpc.async.ResourceLimiter
-
getHeapSize.
- getHttpTransportFactory() - Static method in class com.google.cloud.bigtable.config.CredentialFactory
- getIamPolicy(GetIamPolicyRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableInstanceClient
-
Get an IAM policy.
- getIamPolicy(GetIamPolicyRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableInstanceGrpcClient
-
Get an IAM policy.
- getIndexScanHint(Filter) - Method in class com.google.cloud.bigtable.hbase.adapters.filters.FilterAdapter
- getIndexScanHint(FilterList) - Method in class com.google.cloud.bigtable.hbase.adapters.filters.FilterListAdapter
- getIndexScanHint(MultiRowRangeFilter) - Method in class com.google.cloud.bigtable.hbase.adapters.filters.MultiRowRangeFilterAdapter
- getIndexScanHint(PrefixFilter) - Method in class com.google.cloud.bigtable.hbase.adapters.filters.PrefixFilterAdapter
- getIndexScanHint(Filter) - Method in class com.google.cloud.bigtable.hbase.adapters.filters.SingleFilterAdapter
- getIndexScanHint(S) - Method in interface com.google.cloud.bigtable.hbase.adapters.filters.TypedFilterAdapter
-
Get hints how to optimize the scan.
- getIndexScanHint(S) - Method in class com.google.cloud.bigtable.hbase.adapters.filters.TypedFilterAdapterBase
- getInitialBackoffMillis() - Method in class com.google.cloud.bigtable.config.RetryOptions
-
The amount of time in milliseconds we will wait for our first error retry.
- getInputStream() - Method in class com.google.cloud.bigtable.config.CredentialOptions.JsonCredentialsOptions
- getInputStreamCredential(InputStream) - Static method in class com.google.cloud.bigtable.config.CredentialFactory
-
Initializes OAuth2 application default credentials based on an inputStream.
- getInstance(BigtableInstanceName) - Static method in class com.google.cloud.bigtable.grpc.async.ResourceLimiterStats
- getInstance() - Static method in class com.google.cloud.bigtable.grpc.BigtableSessionSharedThreadPools
-
Get the shared instance of ThreadPools.
- getInstance() - Static method in class com.google.cloud.bigtable.grpc.io.CredentialInterceptorCache
-
Getter for the field
instance
. - getInstanceAdminClient() - Method in class com.google.cloud.bigtable.grpc.BigtableSession
-
Getter for the field
instanceAdminClient
. - getInstanceId() - Method in class com.google.cloud.bigtable.config.BigtableOptions
-
Getter for the field
instanceId
. - getInstanceId() - Method in class com.google.cloud.bigtable.grpc.BigtableClusterName
- getInstanceId() - Method in class com.google.cloud.bigtable.grpc.BigtableInstanceName
- getInstanceId() - Method in class com.google.cloud.bigtable.grpc.BigtableSnapshotName
- getInstanceId() - Method in class com.google.cloud.bigtable.grpc.BigtableTableName
- getInstanceName() - Method in class com.google.cloud.bigtable.config.BigtableOptions
-
Getter for the field
instanceName
. - getInstanceName() - Method in class com.google.cloud.bigtable.grpc.BigtableInstanceName
- getKey(FlatRow) - Method in class com.google.cloud.bigtable.grpc.scanner.FlatRowAdapter
- getKey() - Method in class com.google.cloud.bigtable.util.RowKeyWrapper
- getKeyFile() - Method in class com.google.cloud.bigtable.config.CredentialOptions.P12CredentialOptions
-
P12 file - https://developers.google.com/identity/protocols/OAuth2ServiceAccount
- getLabels() - Method in class com.google.cloud.bigtable.grpc.scanner.FlatRow.Cell
- getLastCompletedRowKey() - Method in class com.google.cloud.bigtable.grpc.scanner.RowMerger
- getLastMajorCompactionTimestamp(TableName) - Method in class com.google.cloud.bigtable.hbase1_x.BigtableAdmin
- getLastMajorCompactionTimestamp(TableName) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- getLastMajorCompactionTimestamp(TableName) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- getLastMajorCompactionTimestampForRegion(byte[]) - Method in class com.google.cloud.bigtable.hbase1_x.BigtableAdmin
- getLastMajorCompactionTimestampForRegion(byte[]) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- getLastMajorCompactionTimestampForRegion(byte[]) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- getLevel() - Method in enum com.google.cloud.bigtable.metrics.BigtableClientMetrics.MetricLevel
- getLevelToLog() - Static method in class com.google.cloud.bigtable.metrics.BigtableClientMetrics
- getLocks() - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- getLocks() - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- getLog() - Method in class com.google.cloud.bigtable.config.Logger
-
Get the underlying
Log
- getLongRpcTimeoutMs() - Method in class com.google.cloud.bigtable.config.CallOptionsConfig
-
Deprecated.
- getMasterAddress() - Method in class org.apache.hadoop.hbase.client.BigtableAsyncRegistry
- getMasterCoprocessors() - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- getMasterInfoPort() - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- getMasterInfoPort() - Method in class org.apache.hadoop.hbase.client.BigtableAsyncRegistry
- getMaxElapsedBackoffMillis() - Method in class com.google.cloud.bigtable.config.RetryOptions
-
Maximum amount of time we will retry an operation that is failing.
- getMaxHeapSize() - Method in class com.google.cloud.bigtable.grpc.async.ResourceLimiter
-
Getter for the field
maxHeapSize
. - getMaxInflightRpcs() - Method in class com.google.cloud.bigtable.config.BulkOptions
-
Getter for the field
maxInflightRpcs
. - getMaxMemory() - Method in class com.google.cloud.bigtable.config.BulkOptions
-
Getter for the field
maxMemory
. - getMaxScanTimeoutRetries() - Method in class com.google.cloud.bigtable.config.RetryOptions
-
The maximum number of times to retry after a scan timeout.
- getMetaRegionLocation() - Method in class org.apache.hadoop.hbase.client.BigtableAsyncRegistry
- getMethodDescriptor() - Method in interface com.google.cloud.bigtable.grpc.async.BigtableAsyncRpc
-
getMethodDescriptor.
- getMetricRegistry(BigtableClientMetrics.MetricLevel) - Static method in class com.google.cloud.bigtable.metrics.BigtableClientMetrics
- getMutateRpcTimeoutMs() - Method in class com.google.cloud.bigtable.config.CallOptionsConfig
-
Getter for the field
mutateRpcTimeoutMs
. - getMutationTimer() - Method in class com.google.cloud.bigtable.grpc.async.ResourceLimiterStats
- getMvccVersion() - Method in class com.google.cloud.bigtable.hbase.adapters.read.RowCell
-
Deprecated.
- getName() - Method in class com.google.cloud.bigtable.hbase.AbstractBigtableTable
- getName() - Method in class com.google.cloud.bigtable.hbase.BigtableBufferedMutator
- getName() - Method in class com.google.cloud.bigtable.hbase.BigtableBufferedMutatorHelper
- getName() - Method in class com.google.cloud.bigtable.hbase.BigtableRegionLocator
- getName() - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncBufferedMutator
- getName() - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncTable
- getName() - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncTableRegionLocator
- getNamespaceDescriptor(String) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- getNamespaceDescriptor(String) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- getNext() - Method in class com.google.cloud.bigtable.grpc.scanner.ResponseQueueReader
-
getNext.
- getNextBackoff() - Method in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation
- getNextMergedRow() - Method in class com.google.cloud.bigtable.grpc.scanner.ResponseQueueReader
-
Get the next complete
FlatRow
object from the response queue. - getNextUniqueId() - Method in class com.google.cloud.bigtable.hbase.adapters.filters.FilterAdapterContext
-
Returns the next unique ID as a
String
in this adapter context. - getNumberOfWhileMatchFilters() - Method in class com.google.cloud.bigtable.hbase.adapters.filters.FilterAdapterContext
-
getNumberOfWhileMatchFilters.
- getOnlineRegions(ServerName) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- getOperation(GetOperationRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableInstanceClient
-
Gets the latest state of a long-running operation.
- getOperation(GetOperationRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableInstanceGrpcClient
-
Gets the latest state of a long-running operation.
- getOperationCallOptions() - Method in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation
-
Returns the
CallOptions
that a user set for the entire Operation, which can span multiple RPCs/retries. - getOperationTimeout() - Method in class com.google.cloud.bigtable.hbase.AbstractBigtableTable
- getOperationTimeout(TimeUnit) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncTable
- getOperationTimeout(TimeUnit) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableTable
- getOperationTimeout() - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- getOptions() - Method in class com.google.cloud.bigtable.grpc.BigtableSession
-
Getter for the field
options
. - getOptions() - Method in class org.apache.hadoop.hbase.client.AbstractBigtableConnection
-
Getter for the field
options
. - getOptions() - Method in class org.apache.hadoop.hbase.client.BigtableAsyncConnection
- getOptions() - Method in interface org.apache.hadoop.hbase.client.CommonConnection
-
Getter for the field
options
. - getPort() - Method in class com.google.cloud.bigtable.config.BigtableOptions
-
Getter for the field
port
. - getProcedures() - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- getProcedures() - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- getProjectId() - Method in class com.google.cloud.bigtable.config.BigtableOptions
-
Getter for the field
projectId
. - getProjectId() - Method in class com.google.cloud.bigtable.grpc.BigtableInstanceName
- getProjectId() - Method in class com.google.cloud.bigtable.grpc.BigtableTableName
- getQualifier() - Method in class com.google.cloud.bigtable.grpc.scanner.FlatRow.Cell
- getQualifier() - Method in class com.google.cloud.bigtable.hbase.adapters.read.RowCell
-
Deprecated.
- getQualifierArray() - Method in class com.google.cloud.bigtable.hbase.adapters.read.RowCell
- getQualifierLength() - Method in class com.google.cloud.bigtable.hbase.adapters.read.RowCell
- getQualifierOffset() - Method in class com.google.cloud.bigtable.hbase.adapters.read.RowCell
- getQuota(QuotaFilter) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- getQuota(QuotaFilter) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- getQuotaRetriever(QuotaFilter) - Method in class com.google.cloud.bigtable.hbase1_x.BigtableAdmin
- getQuotaRetriever(QuotaFilter) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- getReadHooks() - Method in class com.google.cloud.bigtable.hbase.adapters.filters.FilterAdapterContext
-
Getter for the field
readHooks
. - getReadPartialRowTimeoutMillis() - Method in class com.google.cloud.bigtable.config.RetryOptions
-
A timeout for reading individual ReadRowsResponse messages from a stream.
- getReadRpcTimeout() - Method in class com.google.cloud.bigtable.hbase.AbstractBigtableTable
- getReadRpcTimeout(TimeUnit) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncTable
- getReadRpcTimeout() - Method in class com.google.cloud.bigtable.hbase2_x.BigtableTable
- getReadRpcTimeout(TimeUnit) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableTable
- getReadStreamRpcTimeoutMs() - Method in class com.google.cloud.bigtable.config.CallOptionsConfig
-
Getter for the field
readStreamRpcTimeoutMs
. - getRegionLocation(byte[]) - Method in class com.google.cloud.bigtable.hbase.BigtableRegionLocator
- getRegionLocation(byte[], boolean) - Method in class com.google.cloud.bigtable.hbase.BigtableRegionLocator
- getRegionLocation(byte[], boolean) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncTableRegionLocator
- getRegionLocation(byte[], int, boolean) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncTableRegionLocator
- getRegionLocator(TableName) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableConnection
- getRegionLocator(TableName) - Method in class org.apache.hadoop.hbase.client.BigtableAsyncConnection
- getRegionMetrics(ServerName, TableName) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- getRegionMetrics(ServerName) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- getRegionMetrics(ServerName, TableName) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- getRegions(ServerName) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- getRegions(TableName) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- getRegions(TableName) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- getRegions(ServerName) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- getRegionsAsync(boolean) - Method in class com.google.cloud.bigtable.hbase.AbstractBigtableRegionLocator
-
The list of regions will be sorted and cover all the possible rows.
- getRegistry() - Method in class com.google.cloud.bigtable.metrics.DropwizardMetricRegistry
- getReplicationPeerConfig(String) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- getReplicationPeerConfig(String) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- getRetryableStatusCodes() - Method in class com.google.cloud.bigtable.config.RetryOptions
-
Returns
Set
ofStatus.Code
that allow RPC retries. - getRetryExecutor() - Method in class com.google.cloud.bigtable.grpc.BigtableSessionSharedThreadPools
-
Getter for the field
retryExecutor
. - getRetryOptions() - Method in class com.google.cloud.bigtable.config.BigtableOptions
-
Options controlling retries.
- getRetryRequest() - Method in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation
- getRetryRequest() - Method in class com.google.cloud.bigtable.grpc.async.MutateRowsRequestManager
- getRetryRequest() - Method in class com.google.cloud.bigtable.grpc.async.RetryingMutateRowsOperation
- getRetryRequest() - Method in class com.google.cloud.bigtable.grpc.scanner.RetryingReadRowsOperation
-
Updates the original request via
ReadRowsRequestManager.buildUpdatedRequest()
. - getRow() - Method in class com.google.cloud.bigtable.hbase.adapters.read.RowCell
-
Deprecated.
- getRowArray() - Method in class com.google.cloud.bigtable.hbase.adapters.read.RowCell
- getRowCountInLastMessage() - Method in class com.google.cloud.bigtable.grpc.scanner.RowMerger
- getRowKey() - Method in class com.google.cloud.bigtable.grpc.scanner.FlatRow.Builder
- getRowKey() - Method in class com.google.cloud.bigtable.grpc.scanner.FlatRow
- getRowLength() - Method in class com.google.cloud.bigtable.hbase.adapters.read.RowCell
- getRowOffset() - Method in class com.google.cloud.bigtable.hbase.adapters.read.RowCell
- getRowSet() - Method in class com.google.cloud.bigtable.hbase.BigtableExtendedScan
- getRpcCallOptions() - Method in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation
-
Create an
CallOptions
that has a fail safe RPC deadline to make sure that unary operations don't stop responding. - getRpcMetrics() - Method in interface com.google.cloud.bigtable.grpc.async.BigtableAsyncRpc
- getRpcTimeout() - Method in class com.google.cloud.bigtable.hbase.AbstractBigtableTable
- getRpcTimeout(TimeUnit) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncTable
- getRpcTimeout(TimeUnit) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableTable
- getRunnable() - Method in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation
- getSampledRowKeysAdapter(TableName, ServerName) - Method in class com.google.cloud.bigtable.hbase.AbstractBigtableRegionLocator
- getSampledRowKeysAdapter(TableName, ServerName) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncTableRegionLocator
- getSampleRowKeys(CloudBigtableTableConfiguration) - Method in interface com.google.cloud.bigtable.batch.common.CloudBigtableService
- getSampleRowKeys(CloudBigtableTableConfiguration) - Method in class com.google.cloud.bigtable.batch.common.CloudBigtableServiceImpl
- getScanner(Scan) - Method in class com.google.cloud.bigtable.hbase.AbstractBigtableTable
- getScanner(byte[]) - Method in class com.google.cloud.bigtable.hbase.AbstractBigtableTable
- getScanner(byte[], byte[]) - Method in class com.google.cloud.bigtable.hbase.AbstractBigtableTable
- getScanner(Scan) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncTable
- getScanTimeout(TimeUnit) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncTable
- getSecurityCapabilities() - Method in class com.google.cloud.bigtable.hbase1_x.BigtableAdmin
- getSecurityCapabilities() - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- getSecurityCapabilities() - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- getSequenceId() - Method in class com.google.cloud.bigtable.hbase.adapters.read.RowCell
- getServiceAccount() - Method in class com.google.cloud.bigtable.config.CredentialOptions.P12CredentialOptions
-
ServiceAccount email address used for the P12 file - https://developers.google.com/identity/protocols/OAuth2ServiceAccount
- getSession() - Method in class org.apache.hadoop.hbase.client.AbstractBigtableConnection
-
Getter for the field
session
. - getSession() - Method in class org.apache.hadoop.hbase.client.BigtableAsyncConnection
- getSession() - Method in interface org.apache.hadoop.hbase.client.CommonConnection
-
Get a
BigtableSession
on which operations can be performed. - getShortRpcTimeoutMs() - Method in class com.google.cloud.bigtable.config.CallOptionsConfig
-
Getter for the field
shortRpcTimeoutMs
. - getSingleCluster() - Method in class com.google.cloud.bigtable.grpc.BigtableClusterUtilities
- getSingleFamilyName(FilterAdapterContext) - Static method in class com.google.cloud.bigtable.hbase.adapters.filters.FilterAdapterHelper
-
Extract a single family name from a FilterAdapterContext.
- getSnapshotAsync(GetSnapshotRequest) - Method in interface com.google.cloud.bigtable.core.IBigtableTableAdminClient
-
Gets metadata information about the specified snapshot.
- getSnapshotAsync(GetSnapshotRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableTableAdminClient
-
Gets metadata information about the specified snapshot.
- getSnapshotAsync(GetSnapshotRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminClientWrapper
- getSnapshotAsync(GetSnapshotRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGCJClient
-
Gets metadata information about the specified snapshot.
- getSnapshotAsync(GetSnapshotRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGrpcClient
-
Gets metadata information about the specified snapshot.
- getSnapshotClusterName() - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- getSnapshotId() - Method in class com.google.cloud.bigtable.grpc.BigtableSnapshotName
- getSnapshotName() - Method in class com.google.cloud.bigtable.grpc.BigtableSnapshotName
- getSplits(JobContext) - Method in class com.google.cloud.bigtable.mapreduce.ShuffledSequenceFileInputFormat
- getStartEndKeys() - Method in class com.google.cloud.bigtable.hbase.BigtableRegionLocator
- getStartKeys() - Method in class com.google.cloud.bigtable.hbase.BigtableRegionLocator
- getStartTimestampInclusive() - Method in class com.google.cloud.bigtable.hbase.filter.TimestampRangeFilter
- getState() - Method in exception com.google.cloud.bigtable.grpc.io.Watchdog.StreamWaitTimeoutException
- getStats() - Static method in class com.google.cloud.bigtable.grpc.io.ChannelPool
- getStatus() - Method in exception com.google.cloud.bigtable.grpc.io.IOExceptionWithStatus
-
Status from the provided OperationRuntimeException.
- getStreamingBufferSize() - Method in class com.google.cloud.bigtable.config.RetryOptions
-
The maximum number of messages to buffer when scanning.
- getTable(String) - Method in interface com.google.cloud.bigtable.core.IBigtableTableAdminClient
-
Gets the details of a table.
- getTable(GetTableRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableTableAdminClient
-
Gets the details of a table.
- getTable(String) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminClientWrapper
-
Gets the details of a table.
- getTable(String) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGCJClient
-
Gets the details of a table.
- getTable(GetTableRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGrpcClient
-
Gets the details of a table.
- getTable(TableName, ExecutorService) - Method in class com.google.cloud.bigtable.hbase1_x.BigtableConnection
- getTable(TableName, ExecutorService) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableConnection
- getTable(TableName) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableConnection
- getTable(String) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableConnection
-
Deprecated.
- getTableAdminClient() - Method in class com.google.cloud.bigtable.grpc.BigtableSession
-
Deprecated.Please use
BigtableSession.getTableAdminClientWrapper()
. - getTableAdminClientWrapper() - Method in class com.google.cloud.bigtable.grpc.BigtableSession
-
Initializes bigtableTableAdminClient based on flag to use GCJ adapter, available in
BigtableOptions
. - getTableAsync(String) - Method in interface com.google.cloud.bigtable.core.IBigtableTableAdminClient
-
Gets the details of a table asynchronously.
- getTableAsync(GetTableRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableTableAdminClient
-
Gets the details of a table asynchronously.
- getTableAsync(String) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminClientWrapper
-
Gets the details of a table asynchronously.
- getTableAsync(String) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGCJClient
-
Gets the details of a table asynchronously.
- getTableAsync(GetTableRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGrpcClient
-
Gets the details of a table asynchronously.
- getTableBuilder(TableName, ExecutorService) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableConnection
- getTableBuilder(TableName) - Method in class org.apache.hadoop.hbase.client.BigtableAsyncConnection
- getTableBuilder(TableName, ExecutorService) - Method in class org.apache.hadoop.hbase.client.BigtableAsyncConnection
- getTableDescriptor() - Method in class com.google.cloud.bigtable.hbase.AbstractBigtableTable
- getTableDescriptor(TableName) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- getTableDescriptors(List<String>) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- getTableDescriptorsByTableName(List<TableName>) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- getTableId() - Method in class com.google.cloud.bigtable.grpc.BigtableTableName
- getTableName() - Method in class com.google.cloud.bigtable.hbase.adapters.HBaseRequestAdapter
-
Getter for the field
tableName
. - getTableNames(String) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
-
Deprecated.
- getTableNameString() - Method in class com.google.cloud.bigtable.hbase.adapters.HBaseRequestAdapter
-
getTableNameString.
- getTableRegions(TableName) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- getTagsArray() - Method in class com.google.cloud.bigtable.hbase.adapters.read.RowCell
- getTagsLength() - Method in class com.google.cloud.bigtable.hbase.adapters.read.RowCell
- getTagsOffset() - Method in class com.google.cloud.bigtable.hbase.adapters.read.RowCell
- getThreadFactory(String, boolean) - Static method in class com.google.cloud.bigtable.util.ThreadUtil
-
Get a
ThreadFactory
suitable for use in the current environment. - getThrottlingTimer() - Method in class com.google.cloud.bigtable.grpc.async.ResourceLimiterStats
- getTimeoutMs() - Method in class com.google.cloud.bigtable.config.CallOptionsConfig
-
Deprecated.
- getTimestamp() - Method in class com.google.cloud.bigtable.grpc.scanner.FlatRow.Cell
- getTimestamp() - Method in class com.google.cloud.bigtable.hbase.adapters.read.RowCell
- getTypeByte() - Method in class com.google.cloud.bigtable.hbase.adapters.read.RowCell
- getTypedFilter(Filter) - Method in class com.google.cloud.bigtable.hbase.adapters.filters.SingleFilterAdapter
-
getTypedFilter.
- getUnknownFeatures(HColumnDescriptor) - Static method in class com.google.cloud.bigtable.hbase.adapters.admin.ColumnDescriptorAdapter
-
Build a list of configuration keys that we don't know how to handle
- getUnsupportedFeatures(HColumnDescriptor) - Static method in class com.google.cloud.bigtable.hbase.adapters.admin.ColumnDescriptorAdapter
-
Build a Map of configuration keys and values describing configuration values we don't support.
- getUserAgent() - Method in class com.google.cloud.bigtable.config.BigtableOptions
-
Gets the user-agent to be appended to User-Agent header when creating new streams for the channel.
- getValue() - Method in class com.google.cloud.bigtable.grpc.scanner.FlatRow.Cell
- getValue() - Method in class com.google.cloud.bigtable.hbase.adapters.read.RowCell
-
Deprecated.
- getValueArray() - Method in class com.google.cloud.bigtable.hbase.adapters.read.RowCell
- getValueLength() - Method in class com.google.cloud.bigtable.hbase.adapters.read.RowCell
- getValueOffset() - Method in class com.google.cloud.bigtable.hbase.adapters.read.RowCell
- getWaitTimeMs() - Method in exception com.google.cloud.bigtable.grpc.io.Watchdog.StreamWaitTimeoutException
- getWriteBufferSize() - Method in class com.google.cloud.bigtable.hbase.AbstractBigtableTable
-
Deprecated.
- getWriteBufferSize() - Method in class com.google.cloud.bigtable.hbase.BigtableBufferedMutator
- getWriteBufferSize() - Method in class com.google.cloud.bigtable.hbase.BigtableBufferedMutatorHelper
- getWriteBufferSize() - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncBufferedMutator
- getWriteRpcTimeout() - Method in class com.google.cloud.bigtable.hbase.AbstractBigtableTable
- getWriteRpcTimeout(TimeUnit) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncTable
- getWriteRpcTimeout() - Method in class com.google.cloud.bigtable.hbase2_x.BigtableTable
- getWriteRpcTimeout(TimeUnit) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableTable
- getZoneId(Cluster) - Static method in class com.google.cloud.bigtable.grpc.BigtableClusterUtilities
- GoogleCloudResourcePrefixInterceptor - Class in com.google.cloud.bigtable.grpc.io
-
Adds a header ("google-cloud-resource-prefix") that usually contains a fully qualified instance or table name.
- GoogleCloudResourcePrefixInterceptor(String) - Constructor for class com.google.cloud.bigtable.grpc.io.GoogleCloudResourcePrefixInterceptor
-
Constructor for GoogleCloudResourcePrefixInterceptor.
- GRPC_RESOURCE_PREFIX_KEY - Static variable in class com.google.cloud.bigtable.grpc.io.GoogleCloudResourcePrefixInterceptor
-
Constant
GRPC_RESOURCE_PREFIX_KEY
- GrpcFuture() - Constructor for class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation.GrpcFuture
H
- hashCode() - Method in class com.google.cloud.bigtable.hbase.adapters.CellDeduplicationHelper.QualifierOnlyKey
- hashCode() - Method in class com.google.cloud.bigtable.hbase.adapters.read.RowCell
-
In line with
RowCell.equals(Object)
, only uses the key portion, not the value. - hasInflightOperations() - Method in class com.google.cloud.bigtable.grpc.async.OperationAccountant
-
hasInflightRequests.
- hasInflightRequests() - Method in class com.google.cloud.bigtable.grpc.async.ResourceLimiter
-
hasInflightRequests.
- hasInflightRequests() - Method in class com.google.cloud.bigtable.hbase.BigtableBufferedMutator
-
hasInflightRequests.
- hasInflightRequests() - Method in class com.google.cloud.bigtable.hbase.BigtableBufferedMutatorHelper
-
hasInflightRequests.
- hasMatchingLabels(FlatRow) - Static method in class com.google.cloud.bigtable.hbase.adapters.filters.BigtableWhileMatchResultScannerAdapter
- hasStatusBeenRecieved() - Method in class com.google.cloud.bigtable.grpc.scanner.StreamObserverAdapter
- hasWhileMatchFilter(Filter) - Static method in class com.google.cloud.bigtable.hbase.AbstractBigtableTable
- hbase2bigtable(long) - Static method in class com.google.cloud.bigtable.hbase.util.TimestampConverter
- HBASE_CLIENT_ASYNC_CONNECTION_IMPL - Static variable in class com.google.cloud.bigtable.hbase.BigtableConfiguration
- HBASE_CLIENT_ASYNC_REGISTRY_IMPL - Static variable in class com.google.cloud.bigtable.hbase.BigtableConfiguration
- HBASE_CLIENT_CONNECTION_IMPL - Static variable in class com.google.cloud.bigtable.hbase.BigtableConfiguration
- hbaseAdapter - Variable in class com.google.cloud.bigtable.hbase.AbstractBigtableTable
- HBaseMutationAdapter - Class in com.google.cloud.bigtable.hbase.adapters
-
Adapt a generic Mutation to a Google Cloud Java
MutationApi
. - HBaseMutationAdapter(MutationAdapter<Delete>, MutationAdapter<Put>, MutationAdapter<Increment>, MutationAdapter<Append>) - Constructor for class com.google.cloud.bigtable.hbase.adapters.HBaseMutationAdapter
-
Constructor for MutationAdapter.
- hbaseMutationAdapter - Variable in class com.google.cloud.bigtable.hbase.adapters.HBaseRequestAdapter.MutationAdapters
- HBaseRequestAdapter - Class in com.google.cloud.bigtable.hbase.adapters
-
Adapts HBase Deletes, Gets, Scans, Puts, RowMutations, Appends and Increments to Bigtable requests.
- HBaseRequestAdapter(BigtableOptions, TableName, Configuration) - Constructor for class com.google.cloud.bigtable.hbase.adapters.HBaseRequestAdapter
-
Constructor for HBaseRequestAdapter.
- HBaseRequestAdapter(BigtableOptions, TableName, HBaseRequestAdapter.MutationAdapters) - Constructor for class com.google.cloud.bigtable.hbase.adapters.HBaseRequestAdapter
-
Constructor for HBaseRequestAdapter.
- HBaseRequestAdapter.MutationAdapters - Class in com.google.cloud.bigtable.hbase.adapters
- hbaseToTimestampRangeFilter(long, long) - Static method in class com.google.cloud.bigtable.hbase.adapters.filters.TimestampFilterUtil
-
Converts a [startMs, endMs) timestamps to a Cloud Bigtable [startMicros, endMicros) filter.
- HBaseTracingUtilities - Class in com.google.cloud.bigtable.hbase.util
-
These utilities are to be used in conjunction with the opencensus-contrib-zpages artifact.
- HeaderInterceptor - Class in com.google.cloud.bigtable.grpc.io
-
Adds a header ("google-cloud-resource-prefix") that usually contains a fully qualified instance or table name.
- HeaderInterceptor(Metadata.Key<String>, String) - Constructor for class com.google.cloud.bigtable.grpc.io.HeaderInterceptor
-
Constructor for GoogleCloudResourcePrefixInterceptor.
I
- IBigtableDataClient - Interface in com.google.cloud.bigtable.core
-
Interface to wrap
BigtableDataClient
with Google-Cloud-java's models. - IBigtableTableAdminClient - Interface in com.google.cloud.bigtable.core
-
Interface to wrap
BigtableTableAdminClient
with Google-Cloud-java's models. - IBulkMutation - Interface in com.google.cloud.bigtable.core
-
Interface to support batching multiple
RowMutation
request into a single grpc request. - ifMatches(CompareFilter.CompareOp, byte[]) - Method in class com.google.cloud.bigtable.hbase.adapters.CheckAndMutateUtil.RequestBuilder
-
For non-null values, this produces a
RowFilter
equivalent to: - ifNotExists() - Method in class com.google.cloud.bigtable.hbase.adapters.CheckAndMutateUtil.RequestBuilder
- IGNORED_OPTION_KEYS - Static variable in class com.google.cloud.bigtable.hbase.adapters.admin.ColumnDescriptorAdapter
-
Configuration keys that we ignore unconditionally
- Import - Class in com.google.cloud.bigtable.mapreduce
-
Import data written by
Export
. - Import() - Constructor for class com.google.cloud.bigtable.mapreduce.Import
- Import.Importer - Class in com.google.cloud.bigtable.mapreduce
-
Write table content out to files.
- Import.KeyValueImporter - Class in com.google.cloud.bigtable.mapreduce
-
A mapper that just writes out KeyValues.
- Importer() - Constructor for class com.google.cloud.bigtable.mapreduce.Import.Importer
- inc() - Method in interface com.google.cloud.bigtable.metrics.Counter
- increment(Increment) - Method in class com.google.cloud.bigtable.hbase.AbstractBigtableTable
- increment(Increment) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncTable
- INCREMENT_ADAPTER - Static variable in class com.google.cloud.bigtable.hbase.adapters.Adapters
-
Constant
INCREMENT_ADAPTER
- IncrementAdapter - Class in com.google.cloud.bigtable.hbase.adapters
-
Adapter for HBase Increment operations to Bigtable ReadModifyWriteRowRequest.Builder.
- IncrementAdapter() - Constructor for class com.google.cloud.bigtable.hbase.adapters.IncrementAdapter
- incrementColumnValue(byte[], byte[], byte[], long) - Method in class com.google.cloud.bigtable.hbase.AbstractBigtableTable
- incrementColumnValue(byte[], byte[], byte[], long, Durability) - Method in class com.google.cloud.bigtable.hbase.AbstractBigtableTable
- info(String, Object...) - Method in class com.google.cloud.bigtable.config.Logger
-
info
- info(String, Throwable, Object...) - Method in class com.google.cloud.bigtable.config.Logger
-
info
- INITIAL_ELAPSED_BACKOFF_MILLIS_KEY - Static variable in class com.google.cloud.bigtable.hbase.BigtableOptionsFactory
-
Key to set the initial amount of time to wait for retries, given a backoff policy on errors.
- inRetryMode() - Method in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation
- INSTANCE - Static variable in class com.google.cloud.bigtable.hbase.adapters.admin.ColumnDescriptorAdapter
- INSTANCE - Static variable in class com.google.cloud.bigtable.util.ByteStringComparator
- INSTANCE_ID_KEY - Static variable in class com.google.cloud.bigtable.hbase.BigtableOptionsFactory
-
Constant
INSTANCE_ID_KEY="google.bigtable.instance.id"
- instantiateFilter(Configuration) - Static method in class com.google.cloud.bigtable.mapreduce.Import
- interceptCall(MethodDescriptor<ReqT, RespT>, CallOptions, Channel) - Method in class com.google.cloud.bigtable.grpc.async.ThrottlingClientInterceptor
- interceptCall(MethodDescriptor<ReqT, RespT>, CallOptions, Channel) - Method in class com.google.cloud.bigtable.grpc.io.HeaderInterceptor
- interceptCall(MethodDescriptor<ReqT, RespT>, CallOptions, Channel) - Method in class com.google.cloud.bigtable.grpc.io.RefreshingOAuth2CredentialsInterceptor
- interceptCall(MethodDescriptor<ReqT, RespT>, CallOptions, Channel) - Method in class com.google.cloud.bigtable.grpc.io.WatchdogInterceptor
- interruptTask() - Method in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation.GrpcFuture
-
This gets called from
Future.cancel(boolean)
for cancel(true). - IOExceptionWithStatus - Exception in com.google.cloud.bigtable.grpc.io
-
An IOException that carries a gRPC Status object.
- IOExceptionWithStatus(String, Throwable, Status) - Constructor for exception com.google.cloud.bigtable.grpc.io.IOExceptionWithStatus
-
Constructor for IOExceptionWithStatus.
- IOExceptionWithStatus(String, Status) - Constructor for exception com.google.cloud.bigtable.grpc.io.IOExceptionWithStatus
-
Constructor for IOExceptionWithStatus.
- IS_RETRYABLE_MUTATION - Static variable in class com.google.cloud.bigtable.grpc.BigtableDataGrpcClient
-
Constant
IS_RETRYABLE_MUTATION
- isAborted() - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- isAborted() - Method in class org.apache.hadoop.hbase.client.AbstractBigtableConnection
- isAutoFlowControlEnabled() - Method in class com.google.cloud.bigtable.grpc.async.CallController
- isBalancerEnabled() - Method in class com.google.cloud.bigtable.hbase1_x.BigtableAdmin
- isBalancerEnabled() - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- isBalancerEnabled() - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- isCatalogJanitorEnabled() - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- isCatalogJanitorEnabled() - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- isCleanerChoreEnabled() - Method in class com.google.cloud.bigtable.hbase1_x.BigtableAdmin
- isCleanerChoreEnabled() - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- isCleanerChoreEnabled() - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- isClosed() - Method in class org.apache.hadoop.hbase.client.AbstractBigtableConnection
- isEnableBulkMutationThrottling() - Method in class com.google.cloud.bigtable.config.BulkOptions
-
Is an experimental feature of throttling bulk mutation RPCs turned on?
- isEnabled(BigtableClientMetrics.MetricLevel) - Static method in class com.google.cloud.bigtable.metrics.BigtableClientMetrics
-
Checks if a
BigtableClientMetrics.MetricLevel
is enabled; - isFilterAProperSublcass(Filter) - Method in class com.google.cloud.bigtable.hbase.adapters.filters.SingleFilterAdapter
-
isFilterAProperSublcass.
- isFilterSupported(FilterAdapterContext, BigtableFilter) - Method in class com.google.cloud.bigtable.hbase.adapters.filters.BigtableFilterAdapter
- isFilterSupported(FilterAdapterContext, ColumnCountGetFilter) - Method in class com.google.cloud.bigtable.hbase.adapters.filters.ColumnCountGetFilterAdapter
-
Determine if the given filter can be adapted to a Bigtable RowFilter.
- isFilterSupported(FilterAdapterContext, ColumnPaginationFilter) - Method in class com.google.cloud.bigtable.hbase.adapters.filters.ColumnPaginationFilterAdapter
-
Determine if the given filter can be adapted to a Bigtable RowFilter.
- isFilterSupported(FilterAdapterContext, ColumnPrefixFilter) - Method in class com.google.cloud.bigtable.hbase.adapters.filters.ColumnPrefixFilterAdapter
-
Determine if the given filter can be adapted to a Bigtable RowFilter.
- isFilterSupported(FilterAdapterContext, ColumnRangeFilter) - Method in class com.google.cloud.bigtable.hbase.adapters.filters.ColumnRangeFilterAdapter
-
Determine if the given filter can be adapted to a Bigtable RowFilter.
- isFilterSupported(FilterAdapterContext, FamilyFilter) - Method in class com.google.cloud.bigtable.hbase.adapters.filters.FamilyFilterAdapter
-
Determine if the given filter can be adapted to a Bigtable RowFilter.
- isFilterSupported(FilterAdapterContext, FilterList) - Method in class com.google.cloud.bigtable.hbase.adapters.filters.FilterListAdapter
-
Determine if the given filter can be adapted to a Bigtable RowFilter.
- isFilterSupported(FilterAdapterContext, FirstKeyOnlyFilter) - Method in class com.google.cloud.bigtable.hbase.adapters.filters.FirstKeyOnlyFilterAdapter
-
Determine if the given filter can be adapted to a Bigtable RowFilter.
- isFilterSupported(FilterAdapterContext, FuzzyRowFilter) - Method in class com.google.cloud.bigtable.hbase.adapters.filters.FuzzyRowFilterAdapter
-
Determine if the given filter can be adapted to a Bigtable RowFilter.
- isFilterSupported(FilterAdapterContext, KeyOnlyFilter) - Method in class com.google.cloud.bigtable.hbase.adapters.filters.KeyOnlyFilterAdapter
-
Determine if the given filter can be adapted to a Bigtable RowFilter.
- isFilterSupported(FilterAdapterContext, MultipleColumnPrefixFilter) - Method in class com.google.cloud.bigtable.hbase.adapters.filters.MultipleColumnPrefixFilterAdapter
-
Determine if the given filter can be adapted to a Bigtable RowFilter.
- isFilterSupported(FilterAdapterContext, MultiRowRangeFilter) - Method in class com.google.cloud.bigtable.hbase.adapters.filters.MultiRowRangeFilterAdapter
- isFilterSupported(FilterAdapterContext, PageFilter) - Method in class com.google.cloud.bigtable.hbase.adapters.filters.PageFilterAdapter
-
Determine if the given filter can be adapted to a Bigtable RowFilter.
- isFilterSupported(FilterAdapterContext, PrefixFilter) - Method in class com.google.cloud.bigtable.hbase.adapters.filters.PrefixFilterAdapter
-
Determine if the given filter can be adapted to a Bigtable RowFilter.
- isFilterSupported(FilterAdapterContext, QualifierFilter) - Method in class com.google.cloud.bigtable.hbase.adapters.filters.QualifierFilterAdapter
-
Determine if the given filter can be adapted to a Bigtable RowFilter.
- isFilterSupported(FilterAdapterContext, RandomRowFilter) - Method in class com.google.cloud.bigtable.hbase.adapters.filters.RandomRowFilterAdapter
-
Determine if the given filter can be adapted to a Bigtable RowFilter.
- isFilterSupported(FilterAdapterContext, RowFilter) - Method in class com.google.cloud.bigtable.hbase.adapters.filters.RowFilterAdapter
-
Determine if the given filter can be adapted to a Bigtable RowFilter.
- isFilterSupported(FilterAdapterContext, SingleColumnValueExcludeFilter) - Method in class com.google.cloud.bigtable.hbase.adapters.filters.SingleColumnValueExcludeFilterAdapter
-
Determine if the given filter can be adapted to a Bigtable RowFilter.
- isFilterSupported(FilterAdapterContext, SingleColumnValueFilter) - Method in class com.google.cloud.bigtable.hbase.adapters.filters.SingleColumnValueFilterAdapter
-
Determine if the given filter can be adapted to a Bigtable RowFilter.
- isFilterSupported(FilterAdapterContext, TimestampRangeFilter) - Method in class com.google.cloud.bigtable.hbase.adapters.filters.TimestampRangeFilterAdapter
- isFilterSupported(FilterAdapterContext, TimestampsFilter) - Method in class com.google.cloud.bigtable.hbase.adapters.filters.TimestampsFilterAdapter
-
Determine if the given filter can be adapted to a Bigtable RowFilter.
- isFilterSupported(FilterAdapterContext, S) - Method in interface com.google.cloud.bigtable.hbase.adapters.filters.TypedFilterAdapter
-
Determine if the given filter can be adapted to a Bigtable RowFilter.
- isFilterSupported(FilterAdapterContext, ValueFilter) - Method in class com.google.cloud.bigtable.hbase.adapters.filters.ValueFilterAdapter
-
Determine if the given filter can be adapted to a Bigtable RowFilter.
- isFilterSupported(FilterAdapterContext, WhileMatchFilter) - Method in class com.google.cloud.bigtable.hbase.adapters.filters.WhileMatchFilterAdapter
-
Determine if the given filter can be adapted to a Bigtable RowFilter.
- isFlushed() - Method in interface com.google.cloud.bigtable.core.IBulkMutation
- isFlushed() - Method in class com.google.cloud.bigtable.grpc.async.BulkMutation
- isFlushed() - Method in class com.google.cloud.bigtable.grpc.async.BulkMutationGCJClient
- isFlushed() - Method in class com.google.cloud.bigtable.grpc.async.BulkMutationWrapper
- isFull() - Method in class com.google.cloud.bigtable.grpc.async.ResourceLimiter
-
isFull.
- isGet(ReadRowsRequest) - Static method in class com.google.cloud.bigtable.grpc.CallOptionsFactory.ConfiguredCallOptionsFactory
- isLongRequest(Object) - Static method in class com.google.cloud.bigtable.grpc.CallOptionsFactory.ConfiguredCallOptionsFactory
-
Deprecated.Please use
CallOptionsFactory.ConfiguredCallOptionsFactory.getRequestTimeout(Object)
to fetch long requests timeout. - isMasterInMaintenanceMode() - Method in class com.google.cloud.bigtable.hbase1_x.BigtableAdmin
- isMasterInMaintenanceMode() - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- isMasterInMaintenanceMode() - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- isMergeEnabled() - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- isMergeEnabled() - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- isNormalizerEnabled() - Method in class com.google.cloud.bigtable.hbase1_x.BigtableAdmin
- isNormalizerEnabled() - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- isNormalizerEnabled() - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- isProcedureFinished(String, String, Map<String, String>) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- isProcedureFinished(String, String, Map<String, String>) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- isReady() - Method in class com.google.cloud.bigtable.grpc.async.CallController
- isRequestRetryable() - Method in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation
- isRequestRetryable() - Method in class com.google.cloud.bigtable.grpc.scanner.RetryingReadRowsOperation
-
All read rows requests are retryable.
- isRetryable(Status.Code) - Method in class com.google.cloud.bigtable.config.RetryOptions
-
Determines if the RPC should be retried based on the input
Status.Code
. - isRetryable(REQUEST) - Method in interface com.google.cloud.bigtable.grpc.async.BigtableAsyncRpc
-
Can this request be retried?
- isScanMarkerRow(FlatRow) - Method in class com.google.cloud.bigtable.grpc.scanner.FlatRowAdapter
- isShutdown() - Method in class com.google.cloud.bigtable.grpc.io.ChannelPool
- isSnapshotFinished(HBaseProtos.SnapshotDescription) - Method in class com.google.cloud.bigtable.hbase1_x.BigtableAdmin
- isSnapshotFinished(SnapshotDescription) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- isSnapshotFinished(SnapshotDescription) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- isSplitEnabled() - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- isSplitEnabled() - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- isSplitOrMergeEnabled(MasterSwitchType) - Method in class com.google.cloud.bigtable.hbase1_x.BigtableAdmin
- isStreamingRead() - Method in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation
- issueAsyncRowRequests(List<? extends Row>, Object[], Batch.Callback<R>) - Method in class com.google.cloud.bigtable.hbase.BatchExecutor
- isSupported() - Method in class com.google.cloud.bigtable.hbase.adapters.filters.FilterSupportStatus
-
True if the adaptation is supported, false otherwise.
- isSupported(FilterAdapterContext, Filter) - Method in class com.google.cloud.bigtable.hbase.adapters.filters.SingleFilterAdapter
-
Determine if the untyped filter is supported.
- isTableAvailable(TableName) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- isTableAvailable(TableName, byte[][]) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- isTableAvailable(TableName) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- isTableAvailable(TableName, byte[][]) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- isTableDisabled(TableName) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- isTableDisabled(TableName) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- isTableDisabled(String) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
-
Deprecated.
- isTableEnabled(TableName) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- isTableEnabled(TableName) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- isTableEnabled(String) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
-
Deprecated.
- isTerminated() - Method in class com.google.cloud.bigtable.grpc.io.ChannelPool
- isUseTimeout() - Method in class com.google.cloud.bigtable.config.CallOptionsConfig
-
isUseTimeout.
J
- JDK_VERSION - Static variable in class com.google.cloud.bigtable.config.BigtableVersionInfo
- jsonCredentials(InputStream) - Static method in class com.google.cloud.bigtable.config.CredentialOptions
-
jsonCredentials.
- jsonCredentials(String) - Static method in class com.google.cloud.bigtable.config.CredentialOptions
-
jsonCredentials.
- JsonCredentialsOptions(InputStream) - Constructor for class com.google.cloud.bigtable.config.CredentialOptions.JsonCredentialsOptions
K
- KeyOnlyFilterAdapter - Class in com.google.cloud.bigtable.hbase.adapters.filters
-
An adapter for KeyOnlyFilter to a Bigtable strip_value_transform.
- KeyOnlyFilterAdapter() - Constructor for class com.google.cloud.bigtable.hbase.adapters.filters.KeyOnlyFilterAdapter
- KeyValueImporter() - Constructor for class com.google.cloud.bigtable.mapreduce.Import.KeyValueImporter
L
- listAppProfiles(ListAppProfilesRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableInstanceClient
-
List application profiles.
- listAppProfiles(ListAppProfilesRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableInstanceGrpcClient
-
List application profiles.
- listCluster(ListClustersRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableInstanceClient
-
Lists information about clusters in an instance.
- listCluster(ListClustersRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableInstanceGrpcClient
-
Lists information about clusters in an instance.
- listDeadServers() - Method in class com.google.cloud.bigtable.hbase1_x.BigtableAdmin
- listDeadServers() - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- listDeadServers() - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- listDecommissionedRegionServers() - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- listDecommissionedRegionServers() - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- listInstances(ListInstancesRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableInstanceClient
-
Lists all instances in the given project.
- listInstances(ListInstancesRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableInstanceGrpcClient
-
Lists all instances in the given project.
- listNamespaceDescriptors() - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- listNamespaceDescriptors() - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- listProcedures() - Method in class com.google.cloud.bigtable.hbase1_x.BigtableAdmin
- listReplicatedTableCFs() - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- listReplicatedTableCFs() - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- listReplicationPeers() - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- listReplicationPeers(Pattern) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- listReplicationPeers() - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- listReplicationPeers(Pattern) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- listSnapshots() - Method in class com.google.cloud.bigtable.hbase1_x.BigtableAdmin
- listSnapshots(String) - Method in class com.google.cloud.bigtable.hbase1_x.BigtableAdmin
- listSnapshots(Pattern) - Method in class com.google.cloud.bigtable.hbase1_x.BigtableAdmin
- listSnapshots(String) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- listSnapshots(Pattern) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- listSnapshots() - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- listSnapshots() - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- listSnapshots(Pattern) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- listSnapshotsAsync(ListSnapshotsRequest) - Method in interface com.google.cloud.bigtable.core.IBigtableTableAdminClient
-
Lists all snapshots associated with the specified cluster.
- listSnapshotsAsync(ListSnapshotsRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableTableAdminClient
-
Lists all snapshots associated with the specified cluster.
- listSnapshotsAsync(ListSnapshotsRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminClientWrapper
- listSnapshotsAsync(ListSnapshotsRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGCJClient
-
Lists all snapshots associated with the specified cluster.
- listSnapshotsAsync(ListSnapshotsRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGrpcClient
-
Lists all snapshots associated with the specified cluster.
- listTableDescriptors() - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- listTableDescriptors(Pattern) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- listTableDescriptors(List<TableName>) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- listTableDescriptors(Pattern, boolean) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- listTableDescriptors(boolean) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- listTableDescriptors(Pattern, boolean) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- listTableDescriptorsByNamespace(byte[]) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- listTableDescriptorsByNamespace(String) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- listTableDescriptorsByNamespace(String) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- listTableNames(boolean) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- listTableNames(Pattern, boolean) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- listTableNames(String) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
-
Deprecated.
- listTableNames(Pattern) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- listTableNames(Pattern, boolean) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- listTableNames(String, boolean) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- listTableNames() - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
-
Lists all table names for the cluster provided in the configuration.
- listTableNamesByNamespace(String) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- listTableNamesByNamespace(String) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- listTables() - Method in interface com.google.cloud.bigtable.core.IBigtableTableAdminClient
-
Lists the names of all tables in an instance.
- listTables(ListTablesRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableTableAdminClient
-
Lists the names of all tables in an instance.
- listTables() - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminClientWrapper
-
Lists the names of all tables in an instance.
- listTables() - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGCJClient
-
Lists the names of all tables in an instance.
- listTables(ListTablesRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGrpcClient
-
Lists the names of all tables in an instance.
- listTables() - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- listTables(Pattern) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- listTables(Pattern, boolean) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- listTables(String) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- listTables(String, boolean) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- listTablesAsync() - Method in interface com.google.cloud.bigtable.core.IBigtableTableAdminClient
-
Lists the names of all tables in an instance asynchronously.
- listTablesAsync(ListTablesRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableTableAdminClient
-
Lists the names of all tables in an instance asynchronously.
- listTablesAsync() - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminClientWrapper
-
Lists the names of all tables in an instance asynchronously.
- listTablesAsync() - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGCJClient
-
Lists the names of all tables in an instance asynchronously.
- listTablesAsync(ListTablesRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGrpcClient
-
Lists the names of all tables in an instance asynchronously.
- listTableSnapshots(String, String) - Method in class com.google.cloud.bigtable.hbase1_x.BigtableAdmin
- listTableSnapshots(Pattern, Pattern) - Method in class com.google.cloud.bigtable.hbase1_x.BigtableAdmin
- listTableSnapshots(String, String) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- listTableSnapshots(Pattern, Pattern) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- listTableSnapshots(Pattern, Pattern) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- listTableSnapshots(Pattern) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- locatorCache - Variable in class org.apache.hadoop.hbase.client.AbstractBigtableConnection
- LOG - Static variable in class com.google.cloud.bigtable.config.CredentialOptions
-
Constant
LOG
- log - Variable in class com.google.cloud.bigtable.config.Logger
- LOG - Static variable in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation
-
Constant
LOG
- LOG - Static variable in class com.google.cloud.bigtable.grpc.async.BulkRead
-
Constant
LOG
- LOG - Static variable in class com.google.cloud.bigtable.grpc.io.ChannelPool
-
Constant
LOG
- LOG - Static variable in class com.google.cloud.bigtable.grpc.scanner.RowMerger
- LOG - Static variable in class com.google.cloud.bigtable.hbase.AbstractBigtableTable
-
Constant
LOG
- LOG - Static variable in class com.google.cloud.bigtable.hbase.adapters.SampledRowKeysAdapter
-
Constant
LOG
- LOG - Static variable in class com.google.cloud.bigtable.hbase.BatchExecutor
-
Constant
LOG
- LOG - Static variable in class com.google.cloud.bigtable.hbase.BigtableBufferedMutator
- LOG - Static variable in class com.google.cloud.bigtable.hbase.BigtableBufferedMutatorHelper
-
Constant
LOG
- LOG - Static variable in class com.google.cloud.bigtable.hbase.BigtableOptionsFactory
-
Constant
LOG
- LOG - Static variable in class com.google.cloud.bigtable.hbase.BigtableRegionLocator
-
Constant
LOG
- LOG - Variable in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- Logger - Class in com.google.cloud.bigtable.config
-
Wrapper around
Log
to conditionally format messages if a specified log level is enabled. - Logger(Class<?>) - Constructor for class com.google.cloud.bigtable.config.Logger
-
Constructor for Logger.
- LONG_TIMEOUT_MS_DEFAULT - Static variable in class com.google.cloud.bigtable.config.CallOptionsConfig
-
The default duration to wait before timing out RPCs.
- lookupCluster(String, String) - Static method in class com.google.cloud.bigtable.grpc.BigtableClusterUtilities
- lookupInstanceId(String, String, String) - Static method in class com.google.cloud.bigtable.grpc.BigtableClusterUtilities
M
- main(String[]) - Static method in class com.google.cloud.bigtable.hbase.CheckConfig
-
main.
- main(String[]) - Static method in class com.google.cloud.bigtable.mapreduce.Driver
-
main.
- main(String[]) - Static method in class com.google.cloud.bigtable.mapreduce.Export
-
Main entry point.
- main(String[]) - Static method in class com.google.cloud.bigtable.mapreduce.Import
-
Main entry point.
- majorCompact(TableName, CompactType) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- majorCompact(TableName, byte[], CompactType) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- majorCompact(TableName, CompactType) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- majorCompact(TableName, byte[], CompactType) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- majorCompact(TableName) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- majorCompact(TableName, byte[]) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- majorCompactRegion(byte[]) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- majorCompactRegion(byte[], byte[]) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- majorCompactRegion(byte[]) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- majorCompactRegion(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- majorCompactRegionServer(ServerName) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- majorCompactRegionServer(ServerName) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- map(ImmutableBytesWritable, Result, Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, Mutation>.Context) - Method in class com.google.cloud.bigtable.mapreduce.Import.Importer
- map(ImmutableBytesWritable, Result, Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, KeyValue>.Context) - Method in class com.google.cloud.bigtable.mapreduce.Import.KeyValueImporter
- mark() - Method in interface com.google.cloud.bigtable.metrics.Meter
- mark(long) - Method in interface com.google.cloud.bigtable.metrics.Meter
- markCanBeCompleted(long) - Method in class com.google.cloud.bigtable.grpc.async.ResourceLimiter
-
Mark an operation id, as returned by
registerOperationWithHeapSize
, as complete - markFailure() - Method in class com.google.cloud.bigtable.grpc.async.BigtableAsyncRpc.RpcMetrics
- markRetriesExhasted() - Method in class com.google.cloud.bigtable.grpc.async.BigtableAsyncRpc.RpcMetrics
- markRetry() - Method in class com.google.cloud.bigtable.grpc.async.BigtableAsyncRpc.RpcMetrics
- MavenPlaceholder - Class in com.google.cloud.bigtable.hbase
-
This class is here to force generation of source javadoc jars so that the maven release process doesn't complain.
- MAX_ELAPSED_BACKOFF_MILLIS_KEY - Static variable in class com.google.cloud.bigtable.hbase.BigtableOptionsFactory
-
Key to set the maximum amount of time to wait for retries, given a backoff policy on errors.
- MAX_INFLIGHT_RPCS_KEY - Static variable in class com.google.cloud.bigtable.hbase.BigtableOptionsFactory
-
Constant
MAX_INFLIGHT_RPCS_KEY="google.bigtable.buffered.mutator.max.in"{trunked}
- MAX_NUMBER_OF_MUTATIONS - Static variable in class com.google.cloud.bigtable.grpc.async.BulkMutation
- MAX_REGION_AGE_MILLIS - Static variable in class com.google.cloud.bigtable.hbase.AbstractBigtableRegionLocator
-
Constant
MAX_REGION_AGE_MILLIS=60 * 1000
- MAX_RPC_WAIT_TIME_NANOS - Static variable in class com.google.cloud.bigtable.grpc.async.BulkMutation
- MAX_SCAN_TIMEOUT_RETRIES - Static variable in class com.google.cloud.bigtable.hbase.BigtableOptionsFactory
-
Key to set the number of time to retry after a scan timeout
- mergeRegions(byte[], byte[], boolean) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- mergeRegions(byte[], byte[], boolean) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- mergeRegionsAsync(byte[][], boolean) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- mergeRegionsAsync(byte[], byte[], boolean) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- mergeSwitch(boolean, boolean) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- mergeSwitch(boolean) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- meter(BigtableClientMetrics.MetricLevel, String) - Static method in class com.google.cloud.bigtable.metrics.BigtableClientMetrics
-
Creates a named
Meter
. - meter(String) - Method in class com.google.cloud.bigtable.metrics.DropwizardMetricRegistry
-
Creates a named
Meter
that wraps a Dropwizard MetricsMeter
. - Meter - Interface in com.google.cloud.bigtable.metrics
-
A meter metric which measures mean throughput and one-, five-, and fifteen-minute exponentially-weighted moving average throughputs.
- meter(String) - Method in interface com.google.cloud.bigtable.metrics.MetricRegistry
-
Creates a named
Meter
. - MetricRegistry - Interface in com.google.cloud.bigtable.metrics
-
A registry of metric instances.
- modify(HColumnDescriptor) - Method in class com.google.cloud.bigtable.hbase.util.ModifyTableBuilder
- modifyColumn(TableName, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- modifyColumnFamily(ModifyColumnFamiliesRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableTableAdminClient
-
Creates, modifies or deletes a new column family within a specified table.
- modifyColumnFamily(ModifyColumnFamiliesRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGrpcClient
-
Creates, modifies or deletes a new column family within a specified table.
- modifyColumnFamily(TableName, ColumnFamilyDescriptor) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- modifyColumnFamily(TableName, ColumnFamilyDescriptor) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- modifyColumnFamilyAsync(ModifyColumnFamiliesRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableTableAdminClient
-
Creates, modifies or deletes a new column family within a specified table.
- modifyColumnFamilyAsync(ModifyColumnFamiliesRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGrpcClient
-
Creates, modifies or deletes a new column family within a specified table.
- modifyColumnFamilyAsync(TableName, ColumnFamilyDescriptor) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- modifyColumns(TableName, String, String, ModifyTableBuilder) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
-
modifyColumns.
- modifyColumns(String, HColumnDescriptor) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
-
Modify an existing column family on a table.
- modifyFamilies(ModifyColumnFamiliesRequest) - Method in interface com.google.cloud.bigtable.core.IBigtableTableAdminClient
-
Creates, modifies or deletes a new column family within a specified table.
- modifyFamilies(ModifyColumnFamiliesRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminClientWrapper
-
Creates, modifies or deletes a new column family within a specified table.
- modifyFamilies(ModifyColumnFamiliesRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGCJClient
-
Creates, modifies or deletes a new column family within a specified table.
- modifyFamiliesAsync(ModifyColumnFamiliesRequest) - Method in interface com.google.cloud.bigtable.core.IBigtableTableAdminClient
-
Creates, modifies or deletes a new column family within a specified table.
- modifyFamiliesAsync(ModifyColumnFamiliesRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminClientWrapper
-
Creates, modifies or deletes a new column family within a specified table.
- modifyFamiliesAsync(ModifyColumnFamiliesRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGCJClient
-
Creates, modifies or deletes a new column family within a specified table.
- modifyNamespace(NamespaceDescriptor) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- modifyNamespace(NamespaceDescriptor) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- modifyNamespaceAsync(NamespaceDescriptor) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- modifyTable(TableDescriptor) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- modifyTable(TableName, TableDescriptor) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- modifyTable(TableDescriptor) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- modifyTable(TableName, HTableDescriptor) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- modifyTableAsync(TableDescriptor) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- modifyTableAsync(TableName, TableDescriptor) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- ModifyTableBuilder - Class in com.google.cloud.bigtable.hbase.util
-
Utility to create
ModifyColumnFamiliesRequest
from HBaseHColumnDescriptor
s. - move(byte[]) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- move(byte[], ServerName) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- move(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- MultipleColumnPrefixFilterAdapter - Class in com.google.cloud.bigtable.hbase.adapters.filters
-
An adapter to transform an HBase MultipleColumnPrefixFilter into a Bigtable RowFilter with each column prefix in an interleaved stream.
- MultipleColumnPrefixFilterAdapter() - Constructor for class com.google.cloud.bigtable.hbase.adapters.filters.MultipleColumnPrefixFilterAdapter
- MultiRowRangeFilterAdapter - Class in com.google.cloud.bigtable.hbase.adapters.filters
-
Adapter for
MultiRowRangeFilter
, it converts the filter into an index scan hint - MultiRowRangeFilterAdapter() - Constructor for class com.google.cloud.bigtable.hbase.adapters.filters.MultiRowRangeFilterAdapter
- mutate(List<? extends Mutation>) - Method in class com.google.cloud.bigtable.hbase.BigtableBufferedMutator
- mutate(Mutation) - Method in class com.google.cloud.bigtable.hbase.BigtableBufferedMutator
- mutate(List<? extends Mutation>) - Method in class com.google.cloud.bigtable.hbase.BigtableBufferedMutatorHelper
- mutate(Mutation) - Method in class com.google.cloud.bigtable.hbase.BigtableBufferedMutatorHelper
-
Being a Mutation.
- mutate(RowMutations) - Method in class com.google.cloud.bigtable.hbase.BigtableBufferedMutatorHelper
- mutate(List<? extends Mutation>) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncBufferedMutator
- mutate(Mutation) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncBufferedMutator
- mutateRow(RowMutation) - Method in interface com.google.cloud.bigtable.core.IBigtableDataClient
-
Mutate a row atomically.
- mutateRow(MutateRowRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableDataClient
-
Mutate a row atomically.
- mutateRow(RowMutation) - Method in class com.google.cloud.bigtable.grpc.BigtableDataClientWrapper
-
Mutate a row atomically.
- mutateRow(RowMutation) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGCJClient
- mutateRow(MutateRowRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGrpcClient
-
Mutate a row atomically.
- mutateRow(RowMutations) - Method in class com.google.cloud.bigtable.hbase.AbstractBigtableTable
- mutateRow(RowMutations) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncTable
- mutateRowAsync(RowMutation) - Method in interface com.google.cloud.bigtable.core.IBigtableDataClient
-
Mutate a row atomically.
- mutateRowAsync(MutateRowRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableDataClient
-
Mutate a row atomically.
- mutateRowAsync(RowMutation) - Method in class com.google.cloud.bigtable.grpc.BigtableDataClientWrapper
-
Mutate a row atomically.
- mutateRowAsync(RowMutation) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGCJClient
- mutateRowAsync(MutateRowRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGrpcClient
-
Mutate a row atomically.
- mutateRows(MutateRowsRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableDataClient
-
Mutates multiple rows in a batch.
- mutateRows(MutateRowsRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGrpcClient
-
Mutates multiple rows in a batch.
- mutateRowsAsync(MutateRowsRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableDataClient
-
Mutates multiple rows in a batch.
- mutateRowsAsync(MutateRowsRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGrpcClient
-
Mutates multiple rows in a batch.
- MutateRowsRequestManager - Class in com.google.cloud.bigtable.grpc.async
-
Performs retries for
BigtableDataClient.mutateRows(MutateRowsRequest)
operations. - MutateRowsRequestManager(RetryOptions, MutateRowsRequest) - Constructor for class com.google.cloud.bigtable.grpc.async.MutateRowsRequestManager
- MutateRowsRequestManager.ProcessingStatus - Enum in com.google.cloud.bigtable.grpc.async
- MutationAdapter<T extends Row> - Class in com.google.cloud.bigtable.hbase.adapters
-
Adapt an HBase
Row
Operation into a Google Cloud JavaMutationApi
. - MutationAdapter() - Constructor for class com.google.cloud.bigtable.hbase.adapters.MutationAdapter
- mutationAdapter - Variable in class com.google.cloud.bigtable.hbase.adapters.RowMutationsAdapter
- mutationAdapters - Variable in class com.google.cloud.bigtable.hbase.adapters.HBaseRequestAdapter
- MutationAdapters(BigtableOptions, Configuration) - Constructor for class com.google.cloud.bigtable.hbase.adapters.HBaseRequestAdapter.MutationAdapters
N
- newBuilder() - Static method in class com.google.cloud.bigtable.grpc.scanner.FlatRow.Cell
- newBuilder() - Static method in class com.google.cloud.bigtable.grpc.scanner.FlatRow
- newBuilder(TableName) - Static method in class com.google.cloud.bigtable.hbase.util.ModifyTableBuilder
- newCall(CallOptions) - Method in interface com.google.cloud.bigtable.grpc.async.BigtableAsyncRpc
-
Creates a
ClientCall
it. - newCall(MethodDescriptor<ReqT, RespT>, CallOptions) - Method in class com.google.cloud.bigtable.grpc.io.ChannelPool
- newCompositeNotSupported(List<FilterSupportStatus>) - Static method in class com.google.cloud.bigtable.hbase.adapters.filters.FilterSupportStatus
-
Static constructor for a not supported status caused by sub-filters not being supported.
- newNotSupported(String) - Static method in class com.google.cloud.bigtable.hbase.adapters.filters.FilterSupportStatus
-
Generic static constructor for not supported adaptations with the stated reason.
- newUnknownFilterType(Filter) - Static method in class com.google.cloud.bigtable.hbase.adapters.filters.FilterSupportStatus
-
Static helper to construct not support adaptations due to no adapter being available for the given Filter type.
- next() - Method in interface com.google.cloud.bigtable.grpc.scanner.ResultScanner
-
Read the next row and block until a row is available.
- next(int) - Method in interface com.google.cloud.bigtable.grpc.scanner.ResultScanner
-
Read the next N rows where N <= count.
- next(int) - Method in class com.google.cloud.bigtable.grpc.scanner.ResumingStreamingResultScanner
-
Read the next N rows where N <= count.
- next() - Method in class com.google.cloud.bigtable.grpc.scanner.ResumingStreamingResultScanner
-
Read the next row and block until a row is available.
- next() - Method in class com.google.cloud.bigtable.grpc.scanner.RowResultScanner
- next(int) - Method in class com.google.cloud.bigtable.grpc.scanner.RowResultScanner
- NO_REGION - Static variable in class com.google.cloud.bigtable.hbase.BatchExecutor
-
For callbacks that take a region, this is the region we will use.
- normalize() - Method in class com.google.cloud.bigtable.hbase1_x.BigtableAdmin
- normalize() - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- normalize() - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- normalizerSwitch(boolean) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- normalizerSwitch(boolean) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- NOT_SUPPORTED_WRONG_TYPE - Static variable in class com.google.cloud.bigtable.hbase.adapters.filters.FilterSupportStatus
-
Used to indicate an internal error where an adapter for a single Filter type is passed an instance of an incompatible Filter type.
- NULL_METRICS_REGISTRY - Static variable in interface com.google.cloud.bigtable.metrics.MetricRegistry
-
An implementation of
MetricRegistry
that doesn't actually track metrics, but doesn't throw a NullPointerException. - nullCredential() - Static method in class com.google.cloud.bigtable.config.CredentialOptions
-
No credentials - used for unit testing.
O
- OAuthCredentialsCache - Class in com.google.cloud.bigtable.grpc.io
-
This class caches calls to
OAuth2Credentials.refreshAccessToken()
. - OAuthCredentialsCache(ExecutorService, OAuth2Credentials) - Constructor for class com.google.cloud.bigtable.grpc.io.OAuthCredentialsCache
-
Constructor for RefreshingOAuth2CredentialsInterceptor.
- offline(byte[]) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- offline(byte[]) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- onClose(Status, Metadata) - Method in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation
- onClose(Status, Metadata) - Method in class com.google.cloud.bigtable.grpc.scanner.OutstandingRequestCountListener
- onClose(Status, Metadata) - Method in class com.google.cloud.bigtable.grpc.scanner.RetryingReadRowsOperation
- onClose(Status, Metadata) - Method in class com.google.cloud.bigtable.grpc.scanner.StreamObserverAdapter
- onCompleted() - Method in class com.google.cloud.bigtable.grpc.async.CallController
- onCompleted() - Method in class com.google.cloud.bigtable.grpc.scanner.ResponseQueueReader
- onCompleted() - Method in class com.google.cloud.bigtable.grpc.scanner.RowMerger
- onError(Status, Metadata) - Method in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation
- onError(Throwable) - Method in class com.google.cloud.bigtable.grpc.async.CallController
- onError(Throwable) - Method in class com.google.cloud.bigtable.grpc.scanner.ResponseQueueReader
- onError(Throwable) - Method in class com.google.cloud.bigtable.grpc.scanner.RowMerger
- onMessage(MutateRowsResponse) - Method in class com.google.cloud.bigtable.grpc.async.MutateRowsRequestManager
-
Adds the content of the message to the
MutateRowsRequestManager.results
. - onMessage(MutateRowsResponse) - Method in class com.google.cloud.bigtable.grpc.async.RetryingMutateRowsOperation
- onMessage(ResponseT) - Method in class com.google.cloud.bigtable.grpc.async.RetryingStreamOperation
- onMessage(ResponseT) - Method in class com.google.cloud.bigtable.grpc.async.RetryingUnaryOperation
- onMessage(ResponseT) - Method in class com.google.cloud.bigtable.grpc.scanner.OutstandingRequestCountListener
- onMessage(ReadRowsResponse) - Method in class com.google.cloud.bigtable.grpc.scanner.RetryingReadRowsOperation
- onMessage(T) - Method in class com.google.cloud.bigtable.grpc.scanner.StreamObserverAdapter
- onNext(RequestT) - Method in class com.google.cloud.bigtable.grpc.async.CallController
- onNext(FlatRow) - Method in class com.google.cloud.bigtable.grpc.scanner.ResponseQueueReader
- onNext(ReadRowsResponse) - Method in class com.google.cloud.bigtable.grpc.scanner.RowMerger
- onOK(Metadata) - Method in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation
-
A subclass has the opportunity to perform the final operations it needs now that the RPC is successfully complete.
- onOK() - Method in class com.google.cloud.bigtable.grpc.async.MutateRowsRequestManager
-
This is called when all calls to
MutateRowsRequestManager.onMessage(MutateRowsResponse)
are complete. - onOK(Metadata) - Method in class com.google.cloud.bigtable.grpc.async.RetryingMutateRowsOperation
- onOK(Metadata) - Method in class com.google.cloud.bigtable.grpc.async.RetryingStreamOperation
-
A subclass has the opportunity to perform the final operations it needs now that the RPC is successfully complete.
- onOK(Metadata) - Method in class com.google.cloud.bigtable.grpc.async.RetryingUnaryOperation
-
A subclass has the opportunity to perform the final operations it needs now that the RPC is successfully complete.
- onOK(Metadata) - Method in class com.google.cloud.bigtable.grpc.scanner.RetryingReadRowsOperation
-
A subclass has the opportunity to perform the final operations it needs now that the RPC is successfully complete.
- OperationAccountant - Class in com.google.cloud.bigtable.grpc.async
-
Throttles the number of operations that are outstanding at any point in time.
- OperationAccountant() - Constructor for class com.google.cloud.bigtable.grpc.async.OperationAccountant
-
Constructor for
OperationAccountant
. - OperationAdapter<T extends Row,U> - Interface in com.google.cloud.bigtable.hbase.adapters
-
An interface for adapters that will convert an HBase Operation into Google Cloud Java Bigtable Models type.
- operationSpan - Variable in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation
- operationTimerContext - Variable in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation
- options - Variable in class com.google.cloud.bigtable.hbase.AbstractBigtableTable
- options - Variable in class com.google.cloud.bigtable.hbase.BatchExecutor
- org.apache.hadoop.hbase.client - package org.apache.hadoop.hbase.client
- OutstandingRequestCountListener<ResponseT> - Class in com.google.cloud.bigtable.grpc.scanner
-
A
ClientCall.Listener
that wraps aStreamObserver
and decrements outstandingRequestCount when a message is received. - OutstandingRequestCountListener(StreamObserver<ResponseT>, AtomicInteger) - Constructor for class com.google.cloud.bigtable.grpc.scanner.OutstandingRequestCountListener
-
Constructor for OutstandingRequestCountListener.
P
- p12Credential(String, String) - Static method in class com.google.cloud.bigtable.config.CredentialOptions
-
Initializes OAuth2 credential from a private keyfile, as described in Service accounts.
- PageFilterAdapter - Class in com.google.cloud.bigtable.hbase.adapters.filters
-
A TypedFilterAdapter for adapting PageFilter instances.
- PageFilterAdapter() - Constructor for class com.google.cloud.bigtable.hbase.adapters.filters.PageFilterAdapter
- parseFrom(byte[]) - Static method in class com.google.cloud.bigtable.hbase.filter.BigtableFilter
- parseFrom(byte[]) - Static method in class com.google.cloud.bigtable.hbase.filter.TimestampRangeFilter
- partialUpdateInstance(PartialUpdateInstanceRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableInstanceClient
-
Partially updates an instance within a project.
- partialUpdateInstance(PartialUpdateInstanceRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableInstanceGrpcClient
-
Partially updates an instance within a project.
- performRetry(long) - Method in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation
- performRetry(long) - Method in class com.google.cloud.bigtable.grpc.scanner.RetryingReadRowsOperation
- PrefixFilterAdapter - Class in com.google.cloud.bigtable.hbase.adapters.filters
-
Adapter for HBase
PrefixFilter
instances. - PrefixFilterAdapter() - Constructor for class com.google.cloud.bigtable.hbase.adapters.filters.PrefixFilterAdapter
- processIntersection(GcRule, HColumnDescriptor) - Static method in class com.google.cloud.bigtable.hbase.adapters.admin.ColumnDescriptorAdapter
-
processIntersection.
- processKV(ImmutableBytesWritable, Result, Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, Mutation>.Context, Put, Delete) - Method in class com.google.cloud.bigtable.mapreduce.Import.Importer
- PROJECT_ID_KEY - Static variable in class com.google.cloud.bigtable.hbase.BigtableOptionsFactory
-
Constant
PROJECT_ID_KEY="google.bigtable.project.id"
- put(Put) - Method in class com.google.cloud.bigtable.hbase.AbstractBigtableTable
- put(List<Put>) - Method in class com.google.cloud.bigtable.hbase.AbstractBigtableTable
- put(Put) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncTable
- put(List<Put>) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncTable
- putAdapter - Variable in class com.google.cloud.bigtable.hbase.adapters.HBaseRequestAdapter.MutationAdapters
- PutAdapter - Class in com.google.cloud.bigtable.hbase.adapters
-
Adapt an HBase
Put
Operation into a Google Cloud JavaMutationApi
. - PutAdapter(int) - Constructor for class com.google.cloud.bigtable.hbase.adapters.PutAdapter
-
Constructor for PutAdapter.
- PutAdapter(int, boolean) - Constructor for class com.google.cloud.bigtable.hbase.adapters.PutAdapter
-
Constructor for PutAdapter.
Q
- qualifier(byte[]) - Method in class com.google.cloud.bigtable.hbase.adapters.CheckAndMutateUtil.RequestBuilder
- QualifierFilterAdapter - Class in com.google.cloud.bigtable.hbase.adapters.filters
-
Adapter for qualifier filters.
- QualifierFilterAdapter() - Constructor for class com.google.cloud.bigtable.hbase.adapters.filters.QualifierFilterAdapter
- QualifierOnlyKey(byte[]) - Constructor for class com.google.cloud.bigtable.hbase.adapters.CellDeduplicationHelper.QualifierOnlyKey
- QuoteFilterExpressionStream(OutputStream) - Constructor for class com.google.cloud.bigtable.hbase.adapters.read.ReaderExpressionHelper.QuoteFilterExpressionStream
- QuoteMetaOutputStream(OutputStream) - Constructor for class com.google.cloud.bigtable.hbase.adapters.read.ReaderExpressionHelper.QuoteMetaOutputStream
- quoteRegularExpression(byte[]) - Static method in class com.google.cloud.bigtable.hbase.adapters.read.ReaderExpressionHelper
-
quoteRegularExpression.
R
- RandomRowFilterAdapter - Class in com.google.cloud.bigtable.hbase.adapters.filters
-
Adapter for
RandomRowFilter
- RandomRowFilterAdapter() - Constructor for class com.google.cloud.bigtable.hbase.adapters.filters.RandomRowFilterAdapter
- READ_BUFFER_SIZE - Static variable in class com.google.cloud.bigtable.hbase.BigtableOptionsFactory
-
Key to set the maximum number of messages to buffer when scanning.
- READ_PARTIAL_ROW_TIMEOUT_MS - Static variable in class com.google.cloud.bigtable.hbase.BigtableOptionsFactory
-
Key to set the amount of time to wait when reading a partial row.
- ReaderExpressionHelper - Class in com.google.cloud.bigtable.hbase.adapters.read
-
Methods and constants to help build a bigtable reader expression // TODO(AngusDavis): Move more ScanAdapter and FilterAdapter writing logic to here.
- ReaderExpressionHelper() - Constructor for class com.google.cloud.bigtable.hbase.adapters.read.ReaderExpressionHelper
- ReaderExpressionHelper.QuoteFilterExpressionStream - Class in com.google.cloud.bigtable.hbase.adapters.read
-
An OutputStream that performs bigtable reader filter expression language quoting of '@', '{', and '}' by pre-pending a '@' to each.
- ReaderExpressionHelper.QuoteMetaOutputStream - Class in com.google.cloud.bigtable.hbase.adapters.read
-
An OutputStream that performs RE2:QuoteMeta as bytes are written.
- readFlatRows(Query) - Method in interface com.google.cloud.bigtable.core.IBigtableDataClient
-
Perform a scan over
FlatRow
s, in key order. - readFlatRows(ReadRowsRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableDataClient
-
Perform a scan over
FlatRow
s, in key order. - readFlatRows(ReadRowsRequest, StreamObserver<FlatRow>) - Method in interface com.google.cloud.bigtable.grpc.BigtableDataClient
-
Perform a streaming read of
FlatRow
s in key order. - readFlatRows(Query) - Method in class com.google.cloud.bigtable.grpc.BigtableDataClientWrapper
-
Perform a scan over
FlatRow
s, in key order. - readFlatRows(Query) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGCJClient
- readFlatRows(ReadRowsRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGrpcClient
-
Perform a scan over
FlatRow
s, in key order. - readFlatRows(ReadRowsRequest, StreamObserver<FlatRow>) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGrpcClient
-
Perform a streaming read of
FlatRow
s in key order. - readFlatRowsAsync(Query) - Method in interface com.google.cloud.bigtable.core.IBigtableDataClient
-
Read multiple
FlatRow
s into an in-memory list, in key order. - readFlatRowsAsync(Query, StreamObserver<FlatRow>) - Method in interface com.google.cloud.bigtable.core.IBigtableDataClient
-
Read
FlatRow
asynchronously, and pass them to a stream observer to be processed. - readFlatRowsAsync(ReadRowsRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableDataClient
-
Read multiple
FlatRow
s into an in-memory list, in key order. - readFlatRowsAsync(Query) - Method in class com.google.cloud.bigtable.grpc.BigtableDataClientWrapper
-
Read multiple
FlatRow
s into an in-memory list, in key order. - readFlatRowsAsync(Query, StreamObserver<FlatRow>) - Method in class com.google.cloud.bigtable.grpc.BigtableDataClientWrapper
-
Read
FlatRow
asynchronously, and pass them to a stream observer to be processed. - readFlatRowsAsync(Query) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGCJClient
- readFlatRowsAsync(Query, StreamObserver<FlatRow>) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGCJClient
- readFlatRowsAsync(ReadRowsRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGrpcClient
-
Read multiple
FlatRow
s into an in-memory list, in key order. - readFlatRowsList(Query) - Method in interface com.google.cloud.bigtable.core.IBigtableDataClient
-
Returns a list of
FlatRow
s, in key order. - readFlatRowsList(ReadRowsRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableDataClient
-
Returns a list of
FlatRow
s, in key order. - readFlatRowsList(Query) - Method in class com.google.cloud.bigtable.grpc.BigtableDataClientWrapper
-
Returns a list of
FlatRow
s, in key order. - readFlatRowsList(Query) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGCJClient
- readFlatRowsList(ReadRowsRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGrpcClient
-
Returns a list of
FlatRow
s, in key order. - ReadHooks - Interface in com.google.cloud.bigtable.hbase.adapters.read
-
Hooks for modifying a
Query
before being sent to Cloud Bigtable. - readModifyWriteRow(ReadModifyWriteRow) - Method in interface com.google.cloud.bigtable.core.IBigtableDataClient
-
Perform an atomic read-modify-write operation on a row.
- readModifyWriteRow(ReadModifyWriteRowRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableDataClient
-
Perform an atomic read-modify-write operation on a row.
- readModifyWriteRow(ReadModifyWriteRow) - Method in class com.google.cloud.bigtable.grpc.BigtableDataClientWrapper
-
Perform an atomic read-modify-write operation on a row.
- readModifyWriteRow(ReadModifyWriteRow) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGCJClient
- readModifyWriteRow(ReadModifyWriteRowRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGrpcClient
-
Perform an atomic read-modify-write operation on a row.
- readModifyWriteRowAsync(ReadModifyWriteRow) - Method in interface com.google.cloud.bigtable.core.IBigtableDataClient
-
Perform an atomic read-modify-write operation on a row.
- readModifyWriteRowAsync(ReadModifyWriteRowRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableDataClient
-
Perform an atomic read-modify-write operation on a row,
- readModifyWriteRowAsync(ReadModifyWriteRow) - Method in class com.google.cloud.bigtable.grpc.BigtableDataClientWrapper
-
Perform an atomic read-modify-write operation on a row.
- readModifyWriteRowAsync(ReadModifyWriteRow) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGCJClient
- readModifyWriteRowAsync(ReadModifyWriteRowRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGrpcClient
-
Perform an atomic read-modify-write operation on a row,
- ReadOperationAdapter<T extends Operation> - Interface in com.google.cloud.bigtable.hbase.adapters.read
-
Interface used for Scan and Get operation adapters.
- readRows(Query) - Method in interface com.google.cloud.bigtable.core.IBigtableDataClient
-
Perform a scan over
Row
s, in key order. - readRows(ReadRowsRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableDataClient
-
Perform a scan over
Row
s, in key order. - readRows(Query) - Method in class com.google.cloud.bigtable.grpc.BigtableDataClientWrapper
-
Perform a scan over
Row
s, in key order. - readRows(Query) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGCJClient
- readRows(ReadRowsRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGrpcClient
-
Perform a scan over
Row
s, in key order. - readRowsAsync(Query) - Method in interface com.google.cloud.bigtable.core.IBigtableDataClient
-
Read multiple
Row
s into an in-memory list, in key order. - readRowsAsync(ReadRowsRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableDataClient
-
Read multiple
Row
s into an in-memory list, in key order. - readRowsAsync(Query) - Method in class com.google.cloud.bigtable.grpc.BigtableDataClientWrapper
-
Read multiple
Row
s into an in-memory list, in key order. - readRowsAsync(Query) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGCJClient
- readRowsAsync(ReadRowsRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGrpcClient
-
Read multiple
Row
s into an in-memory list, in key order. - recommissionRegionServer(ServerName, List<byte[]>) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- recommissionRegionServer(ServerName, List<byte[]>) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- RefreshingOAuth2CredentialsInterceptor - Class in com.google.cloud.bigtable.grpc.io
-
Client interceptor that authenticates all calls by binding header data provided by a credential.
- RefreshingOAuth2CredentialsInterceptor(ExecutorService, OAuth2Credentials) - Constructor for class com.google.cloud.bigtable.grpc.io.RefreshingOAuth2CredentialsInterceptor
-
Constructor for RefreshingOAuth2CredentialsInterceptor.
- registerOperation(ListenableFuture<?>) - Method in class com.google.cloud.bigtable.grpc.async.OperationAccountant
-
Register a new RPC operation.
- registerOperationWithHeapSize(long) - Method in class com.google.cloud.bigtable.grpc.async.ResourceLimiter
-
Register an operation with the given size before sending.
- removeReplicationPeer(String) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- removeReplicationPeer(String) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- removeReplicationPeerAsync(String) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- removeReplicationPeerTableCFs(String, Map<TableName, List<String>>) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- removeReplicationPeerTableCFs(String, Map<TableName, List<String>>) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- request(int) - Method in class com.google.cloud.bigtable.grpc.async.CallController
- requestAdapter - Variable in class com.google.cloud.bigtable.hbase.BatchExecutor
- RequestBuilder(HBaseRequestAdapter, byte[], byte[]) - Constructor for class com.google.cloud.bigtable.hbase.adapters.CheckAndMutateUtil.RequestBuilder
-
RequestBuilder.
- reset() - Method in class com.google.cloud.bigtable.grpc.scanner.FlatRowAdapter.FlatRowBuilder
- resetStatusBasedBackoff() - Method in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation
-
Either a response was found, or a timeout event occurred.
- ResourceLimiter - Class in com.google.cloud.bigtable.grpc.async
-
This class limits access by RPCs to system resources
- ResourceLimiter(ResourceLimiterStats, long, int) - Constructor for class com.google.cloud.bigtable.grpc.async.ResourceLimiter
-
Constructor for ResourceLimiter.
- ResourceLimiterStats - Class in com.google.cloud.bigtable.grpc.async
-
This class tracks timing and counts of mutations performed by
BulkMutation
and throttling performed byResourceLimiter
. - ResourceLimiterStats() - Constructor for class com.google.cloud.bigtable.grpc.async.ResourceLimiterStats
- ResponseAdapter<T,U extends Result> - Interface in com.google.cloud.bigtable.hbase.adapters
-
An adapter for transforming a response from the Bigtable server to a HBase result.
- ResponseQueueReader - Class in com.google.cloud.bigtable.grpc.scanner
-
Manages a queue of
ResultQueueEntry
s ofFlatRow
. - ResponseQueueReader() - Constructor for class com.google.cloud.bigtable.grpc.scanner.ResponseQueueReader
-
Constructor for ResponseQueueReader.
- restoreSnapshot(String, boolean, boolean) - Method in class com.google.cloud.bigtable.hbase1_x.BigtableAdmin
- restoreSnapshot(String, boolean, boolean) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- restoreSnapshot(String) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
-
Restore the specified snapshot on the original table.
- restoreSnapshot(String, boolean) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
-
Restore the specified snapshot on the original table.
- restoreSnapshot(byte[]) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- restoreSnapshot(String) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- restoreSnapshot(byte[], boolean) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- restoreSnapshot(String, boolean) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- restoreSnapshotAsync(String) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- ResultScanner<T> - Interface in com.google.cloud.bigtable.grpc.scanner
-
A scanner of Bigtable rows.
- ResumingStreamingResultScanner - Class in com.google.cloud.bigtable.grpc.scanner
-
A ResultScanner that attempts to resume the readRows call when it encounters gRPC INTERNAL errors.
- ResumingStreamingResultScanner(ResponseQueueReader) - Constructor for class com.google.cloud.bigtable.grpc.scanner.ResumingStreamingResultScanner
-
Constructor for ResumingStreamingResultScanner.
- RETRY_THREAD_COUNT - Static variable in class com.google.cloud.bigtable.grpc.BigtableSessionSharedThreadPools
-
Number of threads to use to initiate retry calls
- retryExecutor - Variable in class com.google.cloud.bigtable.grpc.BigtableSessionSharedThreadPools
-
Used for a few cases that benefit from retries, such as puts, gets and scans.
- retryExecutorService - Variable in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation
- RetryingMutateRowsOperation - Class in com.google.cloud.bigtable.grpc.async
-
Performs retries for
BigtableDataClient.mutateRows(MutateRowsRequest)
operations. - RetryingMutateRowsOperation(RetryOptions, MutateRowsRequest, BigtableAsyncRpc<MutateRowsRequest, MutateRowsResponse>, CallOptions, ScheduledExecutorService, Metadata, ApiClock) - Constructor for class com.google.cloud.bigtable.grpc.async.RetryingMutateRowsOperation
- RetryingReadRowsOperation - Class in com.google.cloud.bigtable.grpc.scanner
-
An extension of
AbstractRetryingOperation
that manages retries for the readRows streaming RPC. - RetryingReadRowsOperation(StreamObserver<FlatRow>, RetryOptions, ReadRowsRequest, BigtableAsyncRpc<ReadRowsRequest, ReadRowsResponse>, CallOptions, ScheduledExecutorService, Metadata, ApiClock) - Constructor for class com.google.cloud.bigtable.grpc.scanner.RetryingReadRowsOperation
- RetryingStreamOperation<RequestT,ResponseT> - Class in com.google.cloud.bigtable.grpc.async
-
An extension of
AbstractRetryingOperation
that aggregates all responses from a streaming request into a List. - RetryingStreamOperation(RetryOptions, RequestT, BigtableAsyncRpc<RequestT, ResponseT>, CallOptions, ScheduledExecutorService, Metadata, ApiClock) - Constructor for class com.google.cloud.bigtable.grpc.async.RetryingStreamOperation
-
Constructor for RetryingCollectingClientCallListener.
- RetryingUnaryOperation<RequestT,ResponseT> - Class in com.google.cloud.bigtable.grpc.async
-
A
AbstractRetryingOperation
for a unary operation. - RetryingUnaryOperation(RetryOptions, RequestT, BigtableAsyncRpc<RequestT, ResponseT>, CallOptions, ScheduledExecutorService, Metadata, ApiClock) - Constructor for class com.google.cloud.bigtable.grpc.async.RetryingUnaryOperation
-
Constructor for RetryingUnaryRpcListener.
- retryOnDeadlineExceeded() - Method in class com.google.cloud.bigtable.config.RetryOptions
-
Whether to retry on deadline exceeded.
- RetryOptions - Class in com.google.cloud.bigtable.config
-
Options for retrying requests, including back off configuration.
- RetryOptions(boolean, boolean, int, double, int, int, int, int, Set<Status.Code>) - Constructor for class com.google.cloud.bigtable.config.RetryOptions
-
Deprecated.
- retryOptions - Variable in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation
- RetryOptions.Builder - Class in com.google.cloud.bigtable.config
-
A Builder for ChannelOptions objects.
- rollWALWriter(ServerName) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- rollWALWriter(ServerName) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- ROW_ADAPTER - Static variable in class com.google.cloud.bigtable.hbase.adapters.Adapters
-
Constant
ROW_ADAPTER
- ROW_RANGE_ADAPTER - Static variable in class com.google.cloud.bigtable.hbase.adapters.Adapters
-
Constant
ROW_RANGE_ADAPTER
- RowAdapter - Class in com.google.cloud.bigtable.hbase.adapters.read
-
Adapt between a
Row
and an hbase clientResult
. - RowAdapter() - Constructor for class com.google.cloud.bigtable.hbase.adapters.read.RowAdapter
- RowCell - Class in com.google.cloud.bigtable.hbase.adapters.read
- RowCell(byte[], byte[], byte[], long, byte[]) - Constructor for class com.google.cloud.bigtable.hbase.adapters.read.RowCell
-
Constructor for RowCell.
- RowFilterAdapter - Class in com.google.cloud.bigtable.hbase.adapters.filters
-
An adapter for row key filters using comparators and operators.
- RowFilterAdapter() - Constructor for class com.google.cloud.bigtable.hbase.adapters.filters.RowFilterAdapter
- RowKeyUtil - Class in com.google.cloud.bigtable.util
- RowKeyUtil() - Constructor for class com.google.cloud.bigtable.util.RowKeyUtil
- RowKeyWrapper - Class in com.google.cloud.bigtable.util
- RowKeyWrapper(ByteString) - Constructor for class com.google.cloud.bigtable.util.RowKeyWrapper
- RowMerger - Class in com.google.cloud.bigtable.grpc.scanner
-
Builds a complete
FlatRow
fromReadRowsResponse
objects. - RowMerger(StreamObserver<FlatRow>) - Constructor for class com.google.cloud.bigtable.grpc.scanner.RowMerger
-
Constructor for RowMerger.
- rowMutationsAdapter - Variable in class com.google.cloud.bigtable.hbase.adapters.HBaseRequestAdapter.MutationAdapters
- RowMutationsAdapter - Class in com.google.cloud.bigtable.hbase.adapters
-
An adapter that adapts a
RowMutations
object into Google Cloud JavaMutationApi
. - RowMutationsAdapter(MutationAdapter<Mutation>) - Constructor for class com.google.cloud.bigtable.hbase.adapters.RowMutationsAdapter
-
Constructor for RowMutationsAdapter.
- RowRangeAdapter - Class in com.google.cloud.bigtable.hbase.adapters.read
-
Adapter to convert between a Bigtable
RowSet
and guava'sRangeSet
. - RowRangeAdapter() - Constructor for class com.google.cloud.bigtable.hbase.adapters.read.RowRangeAdapter
- RowResultScanner<T> - Class in com.google.cloud.bigtable.grpc.scanner
-
A
ResultScanner
that wraps GCJServerStream
. - RowResultScanner(ServerStream<T>, T[]) - Constructor for class com.google.cloud.bigtable.grpc.scanner.RowResultScanner
- rpc - Variable in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation
- rpcTimerContext - Variable in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation
- run() - Method in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation
-
Calls
BigtableAsyncRpc.newCall(CallOptions)
andBigtableAsyncRpc.start(Object, io.grpc.ClientCall.Listener, Metadata, ClientCall)
} with this as the listener so that retries happen correctly. - run() - Method in class com.google.cloud.bigtable.grpc.async.RetryingStreamOperation
-
Calls
BigtableAsyncRpc.newCall(CallOptions)
andBigtableAsyncRpc.start(Object, io.grpc.ClientCall.Listener, Metadata, ClientCall)
} with this as the listener so that retries happen correctly. - run() - Method in class com.google.cloud.bigtable.grpc.io.Watchdog
- run() - Method in class com.google.cloud.bigtable.grpc.scanner.RetryingReadRowsOperation
- run(String[]) - Method in class com.google.cloud.bigtable.mapreduce.Import
- runCatalogJanitor() - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- runCatalogJanitor() - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- runCatalogScan() - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- runCleanerChore() - Method in class com.google.cloud.bigtable.hbase1_x.BigtableAdmin
- runCleanerChore() - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- runCleanerChore() - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
S
- SampledRowKeysAdapter - Class in com.google.cloud.bigtable.hbase.adapters
-
SampledRowKeysAdapter class.
- SampledRowKeysAdapter(TableName, ServerName) - Constructor for class com.google.cloud.bigtable.hbase.adapters.SampledRowKeysAdapter
-
Constructor for SampledRowKeysAdapter.
- sampleRowKeys(String) - Method in interface com.google.cloud.bigtable.core.IBigtableDataClient
-
Sample row keys from a table.
- sampleRowKeys(SampleRowKeysRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableDataClient
-
Sample row keys from a table.
- sampleRowKeys(String) - Method in class com.google.cloud.bigtable.grpc.BigtableDataClientWrapper
-
Sample row keys from a table.
- sampleRowKeys(String) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGCJClient
- sampleRowKeys(SampleRowKeysRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGrpcClient
-
Sample row keys from a table.
- sampleRowKeysAsync(String) - Method in interface com.google.cloud.bigtable.core.IBigtableDataClient
-
Sample row keys from a table, returning a Future that will complete when the sampling has completed.
- sampleRowKeysAsync(SampleRowKeysRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableDataClient
-
Sample row keys from a table, returning a Future that will complete when the sampling has completed.
- sampleRowKeysAsync(String) - Method in class com.google.cloud.bigtable.grpc.BigtableDataClientWrapper
-
Sample row keys from a table, returning a Future that will complete when the sampling has completed.
- sampleRowKeysAsync(String) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGCJClient
- sampleRowKeysAsync(SampleRowKeysRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGrpcClient
-
Sample row keys from a table, returning a Future that will complete when the sampling has completed.
- scan(Scan, ScanResultConsumer) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncTable
- SCAN_ADAPTER - Static variable in class com.google.cloud.bigtable.hbase.adapters.Adapters
-
Constant
SCAN_ADAPTER
- scanAdapter - Variable in class com.google.cloud.bigtable.hbase.adapters.read.GetAdapter
- ScanAdapter - Class in com.google.cloud.bigtable.hbase.adapters.read
-
An adapter for
Scan
operation that makes use of the proto filter language. - ScanAdapter(FilterAdapter, RowRangeAdapter) - Constructor for class com.google.cloud.bigtable.hbase.adapters.read.ScanAdapter
-
Constructor for ScanAdapter.
- scanAll(Scan) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncTable
- ScanHandler - Interface in com.google.cloud.bigtable.grpc.scanner
-
An interface that handles timeout exception situations and request cancellations in scan situations.
- ScanTimeoutException - Exception in com.google.cloud.bigtable.grpc.scanner
-
An IOException that presents timeout when reading response.
- ScanTimeoutException(String) - Constructor for exception com.google.cloud.bigtable.grpc.scanner.ScanTimeoutException
-
Constructor for ScanTimeoutException.
- sendUnsent() - Method in interface com.google.cloud.bigtable.core.IBulkMutation
-
Sends any outstanding
RowMutation
s, present in the current batch. - sendUnsent() - Method in class com.google.cloud.bigtable.grpc.async.BulkMutation
- sendUnsent() - Method in class com.google.cloud.bigtable.grpc.async.BulkMutationGCJClient
-
Sends any outstanding
RowMutation
s, present in the current batch. - sendUnsent() - Method in class com.google.cloud.bigtable.grpc.async.BulkMutationWrapper
-
Sends any outstanding
RowMutation
s, present in the current batch. - sendUnsent() - Method in class com.google.cloud.bigtable.hbase.BigtableBufferedMutatorHelper
- serverName - Variable in class com.google.cloud.bigtable.hbase.adapters.SampledRowKeysAdapter
- SERVICE_ACCOUNT_JSON_ENV_VARIABLE - Static variable in class com.google.cloud.bigtable.config.CredentialOptions
-
Constant
SERVICE_ACCOUNT_JSON_ENV_VARIABLE="GOOGLE_APPLICATION_CREDENTIALS"
- set(RespT) - Method in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation.GrpcFuture
- setAdminHost(String) - Method in class com.google.cloud.bigtable.config.BigtableOptions.Builder
- setAllowRetriesWithoutTimestamp(boolean) - Method in class com.google.cloud.bigtable.config.RetryOptions.Builder
-
Perform retries even if a Put (or other Mutations) don't have a time stamp set and set the timestamp to the server time.
- setAppProfileId(String) - Method in class com.google.cloud.bigtable.config.BigtableOptions.Builder
- setAsyncMutatorWorkerCount(int) - Method in class com.google.cloud.bigtable.config.BulkOptions.Builder
- setAutoflushMs(long) - Method in class com.google.cloud.bigtable.config.BulkOptions.Builder
- setBackoffMultiplier(double) - Method in class com.google.cloud.bigtable.config.RetryOptions.Builder
-
Multiplier we will apply to backoff times between retries.
- setBalancerRunning(boolean, boolean) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- setBulkMaxRequestSize(long) - Method in class com.google.cloud.bigtable.config.BulkOptions.Builder
- setBulkMaxRowKeyCount(int) - Method in class com.google.cloud.bigtable.config.BulkOptions.Builder
- setBulkMutationRpcTargetMs(int) - Method in class com.google.cloud.bigtable.config.BulkOptions.Builder
- setBulkOptions(BulkOptions) - Method in class com.google.cloud.bigtable.config.BigtableOptions.Builder
- setCachedCredentails(Credentials) - Method in class com.google.cloud.bigtable.config.CredentialOptions.JsonCredentialsOptions
- setCallOptionsConfig(CallOptionsConfig) - Method in class com.google.cloud.bigtable.config.BigtableOptions.Builder
- setCallOptionsFactory(CallOptionsFactory) - Method in interface com.google.cloud.bigtable.grpc.BigtableDataClient
-
Sets a
CallOptionsFactory
which createsCallOptions
- setCallOptionsFactory(CallOptionsFactory) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGrpcClient
-
Sets a
CallOptionsFactory
which createsCallOptions
- setCheckExistenceOnly(Get) - Static method in class com.google.cloud.bigtable.hbase.adapters.read.GetAdapter
- setCleanerChoreRunning(boolean) - Method in class com.google.cloud.bigtable.hbase1_x.BigtableAdmin
- setClusterSize(String, String, int) - Method in class com.google.cloud.bigtable.grpc.BigtableClusterUtilities
-
Sets a cluster size to a specific size.
- setClusterSize(int) - Method in class com.google.cloud.bigtable.grpc.BigtableClusterUtilities
-
Sets a cluster size to a specific size in an instance with a single cluster
- setCredentialOptions(CredentialOptions) - Method in class com.google.cloud.bigtable.config.BigtableOptions.Builder
- setCurrentInFlightMaxRpcs(int) - Method in class com.google.cloud.bigtable.grpc.async.ResourceLimiter
-
Setter for the field
currentInFlightMaxRpcs
. - setDataChannelCount(int) - Method in class com.google.cloud.bigtable.config.BigtableOptions.Builder
- setDataHost(String) - Method in class com.google.cloud.bigtable.config.BigtableOptions.Builder
- setEnableRetries(boolean) - Method in class com.google.cloud.bigtable.config.RetryOptions.Builder
-
Enable or disable retries.
- setException(Throwable) - Method in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation.GrpcFuture
- setException(Exception) - Method in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation
- setException(Exception) - Method in class com.google.cloud.bigtable.grpc.scanner.RetryingReadRowsOperation
- setHttpTransportFactory(HttpTransportFactory) - Static method in class com.google.cloud.bigtable.config.CredentialFactory
-
Allow for an override of the credentials HttpTransportFactory.
- setIamPolicy(SetIamPolicyRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableInstanceClient
-
Set an IAM policy.
- setIamPolicy(SetIamPolicyRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableInstanceGrpcClient
-
Set an IAM policy.
- setInitialBackoffMillis(int) - Method in class com.google.cloud.bigtable.config.RetryOptions.Builder
-
The amount of time in milliseconds we will wait for our first error retry.
- setInstanceId(String) - Method in class com.google.cloud.bigtable.config.BigtableOptions.Builder
- setLevelToLog(BigtableClientMetrics.MetricLevel) - Static method in class com.google.cloud.bigtable.metrics.BigtableClientMetrics
-
Set a level at which to log.
- setLongRpcTimeoutMs(int) - Method in class com.google.cloud.bigtable.config.CallOptionsConfig.Builder
-
Deprecated.
- setMaxElapsedBackoffMillis(int) - Method in class com.google.cloud.bigtable.config.RetryOptions.Builder
-
Maximum amount of time we will retry an operation that is failing.
- setMaxInflightRpcs(int) - Method in class com.google.cloud.bigtable.config.BulkOptions.Builder
- setMaxMemory(long) - Method in class com.google.cloud.bigtable.config.BulkOptions.Builder
- setMaxScanTimeoutRetries(int) - Method in class com.google.cloud.bigtable.config.RetryOptions.Builder
-
Set the maximum number of times to retry after a scan timeout.
- setMessageCompression(boolean) - Method in class com.google.cloud.bigtable.grpc.async.CallController
- setMetricRegistry(MetricRegistry) - Static method in class com.google.cloud.bigtable.metrics.BigtableClientMetrics
-
Sets a
MetricRegistry
to be used in all Bigtable connection created after the call. - setMutateRpcTimeoutMs(int) - Method in class com.google.cloud.bigtable.config.CallOptionsConfig.Builder
-
The amount of time in milliseconds to wait before issuing a client side timeout for row mutation RPCs.
- setNormalizerRunning(boolean) - Method in class com.google.cloud.bigtable.hbase1_x.BigtableAdmin
- setOnReadyHandler(Runnable) - Method in class com.google.cloud.bigtable.grpc.async.CallController
- setOperationTimeout(int) - Method in class com.google.cloud.bigtable.hbase.AbstractBigtableTable
- setPort(int) - Method in class com.google.cloud.bigtable.config.BigtableOptions.Builder
- setProjectId(String) - Method in class com.google.cloud.bigtable.config.BigtableOptions.Builder
- setQuota(QuotaSettings) - Method in class com.google.cloud.bigtable.hbase1_x.BigtableAdmin
- setQuota(QuotaSettings) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- setQuota(QuotaSettings) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- setReadPartialRowTimeoutMillis(int) - Method in class com.google.cloud.bigtable.config.RetryOptions.Builder
-
Set the timeout in milliseconds for reading individual ReadRowsResponse messages from a stream.
- setReadRowsRpcTimeoutMs(int) - Method in class com.google.cloud.bigtable.config.CallOptionsConfig.Builder
-
The amount of time in millisecond to wait before issuing a client side timeout for readRows streaming RPCs.
- setReadRpcTimeout(int) - Method in class com.google.cloud.bigtable.hbase.AbstractBigtableTable
- setReadRpcTimeout(int) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableTable
- setResultObserver(StreamObserver<ReadRowsResponse>) - Method in class com.google.cloud.bigtable.grpc.scanner.RetryingReadRowsOperation
- setRetryOnDeadlineExceeded(boolean) - Method in class com.google.cloud.bigtable.config.RetryOptions.Builder
-
Enable or disable retry on deadline exceeded.
- setRetryOptions(RetryOptions) - Method in class com.google.cloud.bigtable.config.BigtableOptions.Builder
- setRowPrefixFilter(byte[]) - Method in class com.google.cloud.bigtable.hbase.BigtableExtendedScan
- setRpcTimeout(int) - Method in class com.google.cloud.bigtable.hbase.AbstractBigtableTable
- setShortRpcTimeoutMs(int) - Method in class com.google.cloud.bigtable.config.CallOptionsConfig.Builder
-
The amount of milliseconds to wait before issuing a client side timeout for short RPCs.
- setSplitOrMergeEnabled(boolean, boolean, MasterSwitchType...) - Method in class com.google.cloud.bigtable.hbase1_x.BigtableAdmin
- setStartRow(byte[]) - Method in class com.google.cloud.bigtable.hbase.BigtableExtendedScan
- setStopRow(byte[]) - Method in class com.google.cloud.bigtable.hbase.BigtableExtendedScan
- setStreamingBufferSize(int) - Method in class com.google.cloud.bigtable.config.RetryOptions.Builder
-
Set the maximum number of messages to buffer when scanning.
- setTimeoutMs(int) - Method in class com.google.cloud.bigtable.config.CallOptionsConfig.Builder
-
Deprecated.
- setup(Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, Mutation>.Context) - Method in class com.google.cloud.bigtable.mapreduce.Import.Importer
- setup(Mapper<ImmutableBytesWritable, Result, ImmutableBytesWritable, KeyValue>.Context) - Method in class com.google.cloud.bigtable.mapreduce.Import.KeyValueImporter
- setupInterceptors() - Method in class com.google.cloud.bigtable.grpc.BigtableSession
- setupTracingConfig() - Static method in class com.google.cloud.bigtable.hbase.util.HBaseTracingUtilities
-
This is a one time setup for grpcz pages.
- setupTracingConfig() - Static method in class com.google.cloud.bigtable.util.TracingUtilities
-
This is a one time setup for grpcz pages.
- setUseBatch(boolean) - Method in class com.google.cloud.bigtable.config.BigtableOptions.Builder
- setUseBulkApi(boolean) - Method in class com.google.cloud.bigtable.config.BulkOptions.Builder
- setUseCachedDataPool(boolean) - Method in class com.google.cloud.bigtable.config.BigtableOptions.Builder
-
This enables an experimental
BigtableSession
feature that caches datapools for cases where there are many HBase Connections / BigtableSessions opened. - setUseGCJClient(boolean) - Method in class com.google.cloud.bigtable.config.BigtableOptions.Builder
- setUsePlaintextNegotiation(boolean) - Method in class com.google.cloud.bigtable.config.BigtableOptions.Builder
- setUserAgent(String) - Method in class com.google.cloud.bigtable.config.BigtableOptions.Builder
- setUseTimeout(boolean) - Method in class com.google.cloud.bigtable.config.CallOptionsConfig.Builder
-
If true, turn on timeouts for unary RPCS like mutations, and single row readRows.
- setWriteBufferSize(long) - Method in class com.google.cloud.bigtable.hbase.AbstractBigtableTable
-
Deprecated.
- setWriteRpcTimeout(int) - Method in class com.google.cloud.bigtable.hbase.AbstractBigtableTable
- setWriteRpcTimeout(int) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableTable
- SHORT_TIMEOUT_MS_DEFAULT - Static variable in class com.google.cloud.bigtable.config.CallOptionsConfig
-
The default duration to wait before timing out RPCs.
- ShuffledSequenceFileInputFormat<K,V> - Class in com.google.cloud.bigtable.mapreduce
-
An InputFormat randomizes the order of SequenceFile splits.
- ShuffledSequenceFileInputFormat() - Constructor for class com.google.cloud.bigtable.mapreduce.ShuffledSequenceFileInputFormat
- shutdown() - Method in class com.google.cloud.bigtable.grpc.io.ChannelPool
- shutdown() - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- shutdown() - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- shutdownNow() - Method in class com.google.cloud.bigtable.grpc.io.ChannelPool
- SingleColumnValueExcludeFilterAdapter - Class in com.google.cloud.bigtable.hbase.adapters.filters
-
Adapter for the
SingleColumnValueFilter
- SingleColumnValueExcludeFilterAdapter(SingleColumnValueFilterAdapter) - Constructor for class com.google.cloud.bigtable.hbase.adapters.filters.SingleColumnValueExcludeFilterAdapter
-
Constructor for SingleColumnValueExcludeFilterAdapter.
- SingleColumnValueFilterAdapter - Class in com.google.cloud.bigtable.hbase.adapters.filters
-
Adapt SingleColumnValueFilter instances into bigtable RowFilters.
- SingleColumnValueFilterAdapter(ValueFilterAdapter) - Constructor for class com.google.cloud.bigtable.hbase.adapters.filters.SingleColumnValueFilterAdapter
-
Constructor for SingleColumnValueFilterAdapter.
- SingleFilterAdapter<T extends Filter> - Class in com.google.cloud.bigtable.hbase.adapters.filters
-
A class that provides untyped-to-typed access to TypedFilterAdapter instances.
- SingleFilterAdapter(Class<T>, TypedFilterAdapter<T>) - Constructor for class com.google.cloud.bigtable.hbase.adapters.filters.SingleFilterAdapter
-
Constructor for SingleFilterAdapter.
- SingleFilterAdapter(Class<T>, TypedFilterAdapter<T>, UnsupportedStatusCollector<T>) - Constructor for class com.google.cloud.bigtable.hbase.adapters.filters.SingleFilterAdapter
-
Constructor for SingleFilterAdapter.
- size() - Method in class com.google.cloud.bigtable.grpc.io.ChannelPool
-
size.
- snapshot(String, TableName, HBaseProtos.SnapshotDescription.Type) - Method in class com.google.cloud.bigtable.hbase1_x.BigtableAdmin
- snapshot(HBaseProtos.SnapshotDescription) - Method in class com.google.cloud.bigtable.hbase1_x.BigtableAdmin
- snapshot(SnapshotDescription) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- snapshot(String, TableName, SnapshotType) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- snapshot(String, TableName) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- snapshot(SnapshotDescription) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- snapshot(String, TableName) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
-
Creates a snapshot from an existing table.
- snapshot(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
-
This is needed for the hbase shell.
- snapshot(byte[], TableName) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- snapshotAsync(SnapshotDescription) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- snapshotTable(String, TableName) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
-
Creates a snapshot from an existing table.
- snapshotTableAsync(SnapshotTableRequest) - Method in interface com.google.cloud.bigtable.core.IBigtableTableAdminClient
-
Creates a new snapshot from a table in a specific cluster.
- snapshotTableAsync(SnapshotTableRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableTableAdminClient
-
Creates a new snapshot from a table in a specific cluster.
- snapshotTableAsync(SnapshotTableRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminClientWrapper
- snapshotTableAsync(SnapshotTableRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGCJClient
-
Creates a new snapshot from a table in a specific cluster.
- snapshotTableAsync(SnapshotTableRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGrpcClient
-
Creates a new snapshot from a table in a specific cluster.
- split(TableName) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- split(TableName, byte[]) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- split(TableName) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- split(TableName, byte[]) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- splitRegion(byte[]) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- splitRegion(byte[], byte[]) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- splitRegion(byte[]) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- splitRegion(byte[], byte[]) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- splitRegionAsync(byte[], byte[]) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- splitSwitch(boolean, boolean) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- splitSwitch(boolean) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- start(REQUEST, ClientCall.Listener<RESPONSE>, Metadata, ClientCall<REQUEST, RESPONSE>) - Method in interface com.google.cloud.bigtable.grpc.async.BigtableAsyncRpc
-
Starts a
ClientCall
. - start(ScheduledExecutorService) - Method in class com.google.cloud.bigtable.grpc.io.Watchdog
- Start - Class in com.google.cloud.bigtable.test.emulator
- Start() - Constructor for class com.google.cloud.bigtable.test.emulator.Start
- startCell(String, ByteString, long, List<String>, long) - Method in class com.google.cloud.bigtable.grpc.scanner.FlatRowAdapter.FlatRowBuilder
- startRow(ByteString) - Method in class com.google.cloud.bigtable.grpc.scanner.FlatRowAdapter.FlatRowBuilder
- STATS - Static variable in class com.google.cloud.bigtable.grpc.io.ChannelPool
- stop() - Method in class com.google.cloud.bigtable.grpc.io.Watchdog
- Stop - Class in com.google.cloud.bigtable.test.emulator
- Stop() - Constructor for class com.google.cloud.bigtable.test.emulator.Stop
- stopMaster() - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- stopMaster() - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- stopRegionServer(ServerName) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- stopRegionServer(String) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- StreamObserverAdapter<T> - Class in com.google.cloud.bigtable.grpc.scanner
-
Adapts a
StreamObserver
to aClientCall.Listener
. - StreamObserverAdapter(ClientCall<?, T>, StreamObserver<T>) - Constructor for class com.google.cloud.bigtable.grpc.scanner.StreamObserverAdapter
-
Constructor for StreamObserverAdapter.
- StreamWaitTimeoutException(Watchdog.State, long) - Constructor for exception com.google.cloud.bigtable.grpc.io.Watchdog.StreamWaitTimeoutException
- SUPPORTED - Static variable in class com.google.cloud.bigtable.hbase.adapters.filters.FilterSupportStatus
-
A static instance for all supported Filter adaptations.
- SUPPORTED_OPTION_KEYS - Static variable in class com.google.cloud.bigtable.hbase.adapters.admin.ColumnDescriptorAdapter
-
Configuration keys that we can support unconditionally and we provide a mapped version of the column descriptor to Bigtable.
- SUPPORTED_OPTION_VALUES - Static variable in class com.google.cloud.bigtable.hbase.adapters.admin.ColumnDescriptorAdapter
-
Configuration option values that we ignore as long as the value is the one specified below.
T
- TABLE_NAME - Static variable in class com.google.cloud.bigtable.mapreduce.Import
-
Constant
TABLE_NAME="import.table.name"
- TABLE_SEPARATOR - Static variable in class com.google.cloud.bigtable.grpc.BigtableInstanceName
-
Constant
TABLE_SEPARATOR="/tables/"
- TableAdapter - Class in com.google.cloud.bigtable.hbase.adapters.admin
-
TableAdapter class.
- TableAdapter(BigtableInstanceName) - Constructor for class com.google.cloud.bigtable.hbase.adapters.admin.TableAdapter
-
Constructor for TableAdapter.
- tableAdapter - Variable in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- TableAdapter2x - Class in com.google.cloud.bigtable.hbase2_x.adapters.admin
-
Need this extended class as
TableAdapter.adapt(HTableDescriptor, CreateTableRequest)
is not binary compatible withTableAdapter2x.adapt(TableDescriptor, byte[][])
- TableAdapter2x(BigtableOptions) - Constructor for class com.google.cloud.bigtable.hbase2_x.adapters.admin.TableAdapter2x
- tableAdminClientWrapper - Variable in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- tableExists(TableName) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- tableExists(TableName) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- tableExists(String) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
-
Deprecated.
- tableName - Variable in class com.google.cloud.bigtable.hbase.AbstractBigtableRegionLocator
- tableName - Variable in class com.google.cloud.bigtable.hbase.AbstractBigtableTable
- tableName - Variable in class com.google.cloud.bigtable.hbase.adapters.HBaseRequestAdapter
- tableName - Variable in class com.google.cloud.bigtable.hbase.adapters.SampledRowKeysAdapter
- takeSnapshotAsync(HBaseProtos.SnapshotDescription) - Method in class com.google.cloud.bigtable.hbase1_x.BigtableAdmin
- testIamPermissions(TestIamPermissionsRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableInstanceClient
-
Tests an IAM policy.
- testIamPermissions(TestIamPermissionsRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableInstanceGrpcClient
-
Tests an IAM policy.
- ThreadUtil - Class in com.google.cloud.bigtable.util
-
Creates a
ThreadFactory
that's safe to use in App Engine. - ThreadUtil() - Constructor for class com.google.cloud.bigtable.util.ThreadUtil
- throttle(int) - Method in class com.google.cloud.bigtable.grpc.async.ResourceLimiter
-
Enable an experimental feature that will throttle requests made from
BulkMutation
. - ThrottlingClientInterceptor - Class in com.google.cloud.bigtable.grpc.async
-
Throttles requests based on
ResourceLimiter
- ThrottlingClientInterceptor(ResourceLimiter) - Constructor for class com.google.cloud.bigtable.grpc.async.ThrottlingClientInterceptor
- throwIfRequestingUnknownFeatures(HColumnDescriptor) - Static method in class com.google.cloud.bigtable.hbase.adapters.admin.ColumnDescriptorAdapter
-
Throw an
UnsupportedOperationException
if the column descriptor cannot be adapted due to it having unknown configuration keys. - throwIfRequestingUnsupportedFeatures(HColumnDescriptor) - Static method in class com.google.cloud.bigtable.hbase.adapters.admin.ColumnDescriptorAdapter
-
Throw an
UnsupportedOperationException
if the column descriptor cannot be adapted due to it having configuration values that are not supported. - throwIfUnsupportedFilter(Scan, Filter) - Method in class com.google.cloud.bigtable.hbase.adapters.filters.FilterAdapter
-
Throw a new UnsupportedFilterException if the given filter cannot be adapted to bigtable reader expressions.
- throwIfUnsupportedScan(Scan) - Method in class com.google.cloud.bigtable.hbase.adapters.read.ScanAdapter
-
throwIfUnsupportedScan.
- time() - Method in interface com.google.cloud.bigtable.metrics.Timer
-
Returns a new
Timer.Context
. - timeOperation() - Method in class com.google.cloud.bigtable.grpc.async.BigtableAsyncRpc.RpcMetrics
- timer(BigtableClientMetrics.MetricLevel, String) - Static method in class com.google.cloud.bigtable.metrics.BigtableClientMetrics
-
Creates a named
Timer
. - timer(String) - Method in class com.google.cloud.bigtable.metrics.DropwizardMetricRegistry
-
Creates a named
Timer
that wraps a Dropwizard MetricsTimer
. - timer(String) - Method in interface com.google.cloud.bigtable.metrics.MetricRegistry
-
Creates a named
Timer
. - Timer - Interface in com.google.cloud.bigtable.metrics
-
A timer metric which aggregates timing durations and provides duration statistics, plus throughput statistics.
- Timer.Context - Interface in com.google.cloud.bigtable.metrics
-
A timing context.
- timeRange(long, long) - Method in class com.google.cloud.bigtable.hbase.adapters.CheckAndMutateUtil.RequestBuilder
- timeRpc() - Method in class com.google.cloud.bigtable.grpc.async.BigtableAsyncRpc.RpcMetrics
- TimestampConverter - Class in com.google.cloud.bigtable.hbase.util
- TimestampConverter() - Constructor for class com.google.cloud.bigtable.hbase.util.TimestampConverter
- TimestampFilterUtil - Class in com.google.cloud.bigtable.hbase.adapters.filters
-
Common utilities for Timestamp filters.
- TimestampFilterUtil() - Constructor for class com.google.cloud.bigtable.hbase.adapters.filters.TimestampFilterUtil
- TimestampRangeFilter - Class in com.google.cloud.bigtable.hbase.filter
-
Defines a filter that only returns cells whose version matches a start and end (both are inclusive)
- TimestampRangeFilter(long, long) - Constructor for class com.google.cloud.bigtable.hbase.filter.TimestampRangeFilter
- TimestampRangeFilterAdapter - Class in com.google.cloud.bigtable.hbase.adapters.filters
-
Converts a
TimestampRangeFilter
into a Cloud BigtableFilters.Filter
. - TimestampRangeFilterAdapter() - Constructor for class com.google.cloud.bigtable.hbase.adapters.filters.TimestampRangeFilterAdapter
- TimestampsFilterAdapter - Class in com.google.cloud.bigtable.hbase.adapters.filters
-
Convert a TimestampsFilter into a RowFilter containing interleaved timestamp range filters.
- TimestampsFilterAdapter() - Constructor for class com.google.cloud.bigtable.hbase.adapters.filters.TimestampsFilterAdapter
- toBuilder() - Method in class com.google.cloud.bigtable.config.BigtableOptions
-
toBuilder.
- toBuilder() - Method in class com.google.cloud.bigtable.config.BulkOptions
-
toBuilder.
- toBuilder() - Method in class com.google.cloud.bigtable.config.CallOptionsConfig
-
toBuilder.
- toBuilder() - Method in class com.google.cloud.bigtable.config.RetryOptions
-
toBuilder.
- toByteArray() - Method in class com.google.cloud.bigtable.hbase.filter.BigtableFilter
- toByteArray() - Method in class com.google.cloud.bigtable.hbase.filter.TimestampRangeFilter
- toClusterName(String) - Method in class com.google.cloud.bigtable.grpc.BigtableInstanceName
- toCompareOp(CompareOperator) - Static method in class com.google.cloud.bigtable.hbase2_x.BigtableTable
- toCompletableFuture(ApiFuture<T>) - Static method in class com.google.cloud.bigtable.hbase2_x.FutureUtils
- toCompletableFuture(ListenableFuture<T>) - Static method in class com.google.cloud.bigtable.hbase2_x.FutureUtils
- toFilter(FilterAdapterContext, ValueFilter) - Method in class com.google.cloud.bigtable.hbase.adapters.filters.ValueFilterAdapter
- toHColumnDescriptor(ColumnFamilyDescriptor) - Static method in class com.google.cloud.bigtable.hbase2_x.adapters.admin.TableAdapter2x
- toRows(Iterable<ReadRowsResponse>) - Static method in class com.google.cloud.bigtable.grpc.scanner.RowMerger
-
toRows.
- toSnapshotName(String) - Method in class com.google.cloud.bigtable.grpc.BigtableClusterName
-
Create a fully qualified snapshot name based on the the clusterName and the snapshotId.
- toString() - Method in class com.google.cloud.bigtable.config.BigtableOptions
- toString() - Method in class com.google.cloud.bigtable.config.BulkOptions
- toString() - Method in class com.google.cloud.bigtable.config.CallOptionsConfig
- toString() - Method in class com.google.cloud.bigtable.config.RetryOptions
- toString() - Method in class com.google.cloud.bigtable.grpc.BigtableClusterName
- toString() - Method in class com.google.cloud.bigtable.grpc.BigtableInstanceName
- toString() - Method in class com.google.cloud.bigtable.grpc.BigtableSnapshotName
-
Returns the fully qualified Snapshot name.
- toString() - Method in class com.google.cloud.bigtable.grpc.BigtableTableName
- toString() - Method in class com.google.cloud.bigtable.grpc.io.HeaderInterceptor
- toString() - Method in class com.google.cloud.bigtable.grpc.scanner.FlatRow.Cell
- toString() - Method in class com.google.cloud.bigtable.grpc.scanner.FlatRow
- toString() - Method in class com.google.cloud.bigtable.hbase.AbstractBigtableTable
- toString() - Method in class com.google.cloud.bigtable.hbase.adapters.filters.FilterSupportStatus
- toString() - Method in class com.google.cloud.bigtable.hbase.adapters.read.RowCell
- toString() - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- toString() - Method in class org.apache.hadoop.hbase.client.AbstractBigtableConnection
- toTableId(String) - Method in class com.google.cloud.bigtable.grpc.BigtableInstanceName
-
Transforms a tableName within this instance of the form projects/(projectId)/instances/(instanceId)/tables/(tableId) to (tableId).
- toTableName(String) - Method in class com.google.cloud.bigtable.grpc.BigtableInstanceName
-
toTableName.
- toTableNameStr(String) - Method in class com.google.cloud.bigtable.grpc.BigtableInstanceName
-
toTableNameStr.
- toTimestampRangeFilter(long, long) - Static method in class com.google.cloud.bigtable.hbase.adapters.filters.TimestampFilterUtil
-
Converts a [startMicros, endNons) timestamps to a Cloud Bigtable [startMicros, endMicros) filter.
- trace(String, Object...) - Method in class com.google.cloud.bigtable.config.Logger
-
trace
- TracingUtilities - Class in com.google.cloud.bigtable.util
-
These utilities are to be used in conjunction with the opencensus-contrib-zpages artifact to display a consistent set of Cloud Bigtable RPC methods.
- transformAndAdapt(ListenableFuture<F>, Function<F, T>) - Static method in class com.google.cloud.bigtable.util.ApiFutureUtil
- truncateTable(TableName, boolean) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- truncateTable(TableName, boolean) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- truncateTableAsync(TableName, boolean) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- TypedFilterAdapter<S extends Filter> - Interface in com.google.cloud.bigtable.hbase.adapters.filters
-
An adapter that can adapt an HBase Filter instance into a Bigtable RowFilter.
- TypedFilterAdapterBase<S extends Filter> - Class in com.google.cloud.bigtable.hbase.adapters.filters
-
Base functionality for all filter adapters
- TypedFilterAdapterBase() - Constructor for class com.google.cloud.bigtable.hbase.adapters.filters.TypedFilterAdapterBase
U
- UNARY_DEADLINE_MINUTES - Static variable in class com.google.cloud.bigtable.grpc.async.AbstractRetryingOperation
- unassign(byte[], boolean) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- unassign(byte[], boolean) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- UnsupportedFilterException - Exception in com.google.cloud.bigtable.hbase.adapters.filters
-
An exception thrown when attempting to adapt unsupported filters.
- UnsupportedFilterException(List<FilterSupportStatus>) - Constructor for exception com.google.cloud.bigtable.hbase.adapters.filters.UnsupportedFilterException
-
Constructor for UnsupportedFilterException.
- UnsupportedMutationAdapter<T extends Mutation> - Class in com.google.cloud.bigtable.hbase.adapters
-
An adapter that throws an Unsupported exception when its adapt method is invoked.
- UnsupportedMutationAdapter(String) - Constructor for class com.google.cloud.bigtable.hbase.adapters.UnsupportedMutationAdapter
-
Constructor for UnsupportedOperationAdapter.
- UnsupportedStatusCollector<S extends Filter> - Interface in com.google.cloud.bigtable.hbase.adapters.filters
-
An interface that classes should implement if they're able to contribute meaningfully to collecting unsupported status objects from child filters.
- update(long, TimeUnit) - Method in interface com.google.cloud.bigtable.metrics.Timer
-
Adds a recorded duration.
- updateAppProfile(UpdateAppProfileRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableInstanceClient
-
/** Update an application profile.
- updateAppProfile(UpdateAppProfileRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableInstanceGrpcClient
-
/** Update an application profile.
- updateCluster(Cluster) - Method in interface com.google.cloud.bigtable.grpc.BigtableInstanceClient
-
Updates a cluster within an instance.
- updateCluster(Cluster) - Method in class com.google.cloud.bigtable.grpc.BigtableInstanceGrpcClient
-
Updates a cluster within an instance.
- updateConfiguration() - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- updateConfiguration(ServerName) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- updateConfiguration(ServerName) - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- updateConfiguration() - Method in class org.apache.hadoop.hbase.client.AbstractBigtableAdmin
- updateHeaders(Metadata) - Method in class com.google.cloud.bigtable.grpc.io.HeaderInterceptor
- updateInstance(Instance) - Method in interface com.google.cloud.bigtable.grpc.BigtableInstanceClient
-
Updates an instance within a project.
- updateInstance(Instance) - Method in class com.google.cloud.bigtable.grpc.BigtableInstanceGrpcClient
-
Updates an instance within a project.
- updateReplicationPeerConfig(String, ReplicationPeerConfig) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- updateReplicationPeerConfig(String, ReplicationPeerConfig) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAsyncAdmin
- updateReplicationPeerConfigAsync(String, ReplicationPeerConfig) - Method in class com.google.cloud.bigtable.hbase2_x.BigtableAdmin
- USE_TIMEOUT_DEFAULT - Static variable in class com.google.cloud.bigtable.config.CallOptionsConfig
-
Constant
USE_TIMEOUT_DEFAULT=false
- useBatch() - Method in class com.google.cloud.bigtable.config.BigtableOptions
- useBulkApi() - Method in class com.google.cloud.bigtable.config.BulkOptions
-
useBulkApi.
- useCachedChannel() - Method in class com.google.cloud.bigtable.config.BigtableOptions
-
Experimental feature to allow situations with multiple connections to optimize their startup time.
- useGCJClient() - Method in class com.google.cloud.bigtable.config.BigtableOptions
-
useGCJClient
- usePlaintextNegotiation() - Method in class com.google.cloud.bigtable.config.BigtableOptions
-
usePlaintextNegotiation.
- UserSuppliedCredentialOptions(Credentials) - Constructor for class com.google.cloud.bigtable.config.CredentialOptions.UserSuppliedCredentialOptions
V
- ValueFilterAdapter - Class in com.google.cloud.bigtable.hbase.adapters.filters
-
Adapt a single HBase ValueFilter.
- ValueFilterAdapter() - Constructor for class com.google.cloud.bigtable.hbase.adapters.filters.ValueFilterAdapter
- valueOf(String) - Static method in enum com.google.cloud.bigtable.config.CredentialOptions.CredentialType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.google.cloud.bigtable.grpc.async.MutateRowsRequestManager.ProcessingStatus
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.google.cloud.bigtable.grpc.io.Watchdog.State
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.google.cloud.bigtable.metrics.BigtableClientMetrics.MetricLevel
-
Returns the enum constant of this type with the specified name.
- values() - Static method in enum com.google.cloud.bigtable.config.CredentialOptions.CredentialType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.google.cloud.bigtable.grpc.async.MutateRowsRequestManager.ProcessingStatus
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.google.cloud.bigtable.grpc.io.Watchdog.State
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.google.cloud.bigtable.metrics.BigtableClientMetrics.MetricLevel
-
Returns an array containing the constants of this enum type, in the order they are declared.
W
- waitForOperation(String, int) - Method in class com.google.cloud.bigtable.grpc.BigtableClusterUtilities
-
Waits for an operation like cluster resizing to complete.
- waitForOperation(Operation) - Method in interface com.google.cloud.bigtable.grpc.BigtableInstanceClient
-
Waits for the long running operation to complete by polling with exponential backoff.
- waitForOperation(Operation, long, TimeUnit) - Method in interface com.google.cloud.bigtable.grpc.BigtableInstanceClient
-
Waits for the long running operation to complete by polling with exponential backoff.
- waitForOperation(Operation) - Method in class com.google.cloud.bigtable.grpc.BigtableInstanceGrpcClient
-
Waits for the long running operation to complete by polling with exponential backoff.
- waitForOperation(Operation, long, TimeUnit) - Method in class com.google.cloud.bigtable.grpc.BigtableInstanceGrpcClient
-
Waits for the long running operation to complete by polling with exponential backoff.
- waitForReplication(BigtableTableName, long) - Method in interface com.google.cloud.bigtable.grpc.BigtableTableAdminClient
-
Blocks until replication has caught up to the point this method was called or timeout is reached.
- waitForReplication(BigtableTableName, long) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGrpcClient
-
Blocks until replication has caught up to the point this method was called or timeout is reached.
- warn(String, Object...) - Method in class com.google.cloud.bigtable.config.Logger
-
warn
- warn(String, Throwable, Object...) - Method in class com.google.cloud.bigtable.config.Logger
-
warn
- wasMutationApplied(ConditionalRowMutation, Boolean) - Static method in class com.google.cloud.bigtable.hbase.adapters.CheckAndMutateUtil
-
wasMutationApplied.
- watch(ClientCall<ReqT, RespT>) - Method in class com.google.cloud.bigtable.grpc.io.Watchdog
- Watchdog - Class in com.google.cloud.bigtable.grpc.io
-
Prevents the streams from becoming unresponsive indefinitely.
- Watchdog(Clock, long) - Constructor for class com.google.cloud.bigtable.grpc.io.Watchdog
- Watchdog(Clock, long, long) - Constructor for class com.google.cloud.bigtable.grpc.io.Watchdog
- Watchdog.State - Enum in com.google.cloud.bigtable.grpc.io
- Watchdog.StreamWaitTimeoutException - Exception in com.google.cloud.bigtable.grpc.io
-
Marker exception to replace cancelled status with aborted to allow retries.
- WatchdogInterceptor - Class in com.google.cloud.bigtable.grpc.io
-
Internal implementation detail to prevent RPC from becoming unresponsive.
- WatchdogInterceptor(Set<MethodDescriptor<?, ?>>, Watchdog) - Constructor for class com.google.cloud.bigtable.grpc.io.WatchdogInterceptor
- WhileMatchFilterAdapter - Class in com.google.cloud.bigtable.hbase.adapters.filters
-
Adapter for
WhileMatchFilter
. - WhileMatchFilterAdapter(FilterAdapter) - Constructor for class com.google.cloud.bigtable.hbase.adapters.filters.WhileMatchFilterAdapter
-
Constructor for WhileMatchFilterAdapter.
- withCredentials(Configuration, Credentials) - Static method in class com.google.cloud.bigtable.hbase.BigtableConfiguration
-
Sets a reference to a
Credentials
in aConfiguration
object. - withDelete(Delete) - Method in class com.google.cloud.bigtable.hbase.adapters.CheckAndMutateUtil.RequestBuilder
- withFamily(String) - Method in class com.google.cloud.bigtable.grpc.scanner.FlatRow.Cell.Builder
- withLabels(List<String>) - Method in class com.google.cloud.bigtable.grpc.scanner.FlatRow.Cell.Builder
- withMutations(RowMutations) - Method in class com.google.cloud.bigtable.hbase.adapters.CheckAndMutateUtil.RequestBuilder
- withPut(Put) - Method in class com.google.cloud.bigtable.hbase.adapters.CheckAndMutateUtil.RequestBuilder
- withQualifier(ByteString) - Method in class com.google.cloud.bigtable.grpc.scanner.FlatRow.Cell.Builder
- withRowKey(ByteString) - Method in class com.google.cloud.bigtable.grpc.scanner.FlatRow.Builder
- withServerSideTimestamps() - Method in class com.google.cloud.bigtable.hbase.adapters.HBaseRequestAdapter.MutationAdapters
- withServerSideTimestamps() - Method in class com.google.cloud.bigtable.hbase.adapters.HBaseRequestAdapter
- withTimestamp(long) - Method in class com.google.cloud.bigtable.grpc.scanner.FlatRow.Cell.Builder
- withValue(ByteString) - Method in class com.google.cloud.bigtable.grpc.scanner.FlatRow.Cell.Builder
- wrap(byte[]) - Static method in class com.google.cloud.bigtable.hbase.util.ByteStringer
-
Wraps a byte array in a
ByteString
without copying it. - wrap(byte[], int, int) - Static method in class com.google.cloud.bigtable.hbase.util.ByteStringer
-
Wraps a byte array in a
ByteString
without copying it. - wrap(byte[]) - Static method in class com.google.cloud.bigtable.hbase.util.ZeroCopyByteStringUtil
-
Wraps a byte array in a
ByteString
without copying it. - write(int) - Method in class com.google.cloud.bigtable.hbase.adapters.read.ReaderExpressionHelper.QuoteFilterExpressionStream
- write(int) - Method in class com.google.cloud.bigtable.hbase.adapters.read.ReaderExpressionHelper.QuoteMetaOutputStream
- writeNullCharacterBytes() - Method in class com.google.cloud.bigtable.hbase.adapters.read.ReaderExpressionHelper.QuoteMetaOutputStream
- writeQuotedExpression(OutputStream, byte[]) - Static method in class com.google.cloud.bigtable.hbase.adapters.read.ReaderExpressionHelper
-
Write unquoted to the OutputStream applying both RE2:QuoteMeta and Bigtable reader expression quoting.
- writeQuotedRegularExpression(OutputStream, byte[]) - Static method in class com.google.cloud.bigtable.hbase.adapters.read.ReaderExpressionHelper
-
Write unquoted to the OutputStream applying RE2:QuoteMeta quoting.
Z
- ZeroCopyByteStringUtil - Class in com.google.cloud.bigtable.hbase.util
-
Helper class to extract byte arrays from
ByteString
without copy. - ZeroCopyByteStringUtil() - Constructor for class com.google.cloud.bigtable.hbase.util.ZeroCopyByteStringUtil