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

A

AbstractBigtableResultScanner - Class in com.google.cloud.bigtable.grpc.scanner
Abstract base class for Bigtable ResultScanner implementations that provides a common next(int) implementation.
AbstractBigtableResultScanner() - Constructor for class com.google.cloud.bigtable.grpc.scanner.AbstractBigtableResultScanner
 
add(ResultQueueEntry<ReadRowsResponse>) - Method in class com.google.cloud.bigtable.grpc.scanner.ResponseQueueReader
 
addCallback(ListenableFuture<T>, Long) - Method in class com.google.cloud.bigtable.grpc.async.HeapSizeManager
 
addListener(Runnable, Executor) - Method in class com.google.cloud.bigtable.grpc.io.CancellationToken
Add a listener that will be fired if and when this token is cancelled.
addPartialRow(ReadRowsResponse) - Method in class com.google.cloud.bigtable.grpc.scanner.RowMerger
Add a partial row response to this builder.
addResult(ReadRowsResponse) - Method in class com.google.cloud.bigtable.grpc.scanner.StreamingBigtableResultScanner
 
ASYNC_MUTATOR_MAX_MEMORY_DEFAULT - Static variable in class com.google.cloud.bigtable.grpc.async.AsyncExecutor
 
AsyncExecutor - Class in com.google.cloud.bigtable.grpc.async
This class provides management of asynchronous Bigtable RPCs.
AsyncExecutor(BigtableDataClient, HeapSizeManager) - Constructor for class com.google.cloud.bigtable.grpc.async.AsyncExecutor
 
AsyncExecutor.AsyncCall<RequestT,ResponseT> - Interface in com.google.cloud.bigtable.grpc.async
 
asyncRefresh() - Method in class com.google.cloud.bigtable.grpc.io.RefreshingOAuth2CredentialsInterceptor
 
asyncServerStreamingCall(ClientCall<ReqT, RespT>, ReqT, StreamObserver<RespT>) - Method in interface com.google.cloud.bigtable.grpc.io.ClientCallService
 
asyncServerStreamingCall(ClientCall<ReqT, RespT>, ReqT, ClientCall.Listener<RespT>) - Method in interface com.google.cloud.bigtable.grpc.io.ClientCallService
 
AsyncUnaryOperationObserver<T> - Class in com.google.cloud.bigtable.grpc.async
A StreamObserver for unary async operations.
AsyncUnaryOperationObserver() - Constructor for class com.google.cloud.bigtable.grpc.async.AsyncUnaryOperationObserver
 
authority() - Method in class com.google.cloud.bigtable.grpc.io.ChannelPool
 
authority() - Method in class com.google.cloud.bigtable.grpc.io.ChannelPool.PooledChannel
 
authority() - Method in class com.google.cloud.bigtable.grpc.io.ReconnectingChannel
 
available() - Method in class com.google.cloud.bigtable.grpc.scanner.ResponseQueueReader
 
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
 
available() - Method in class com.google.cloud.bigtable.grpc.scanner.StreamingBigtableResultScanner
 

B

BATCH_POOL_THREAD_NAME - Static variable in class com.google.cloud.bigtable.grpc.BigtableSession
 
BIGTABLE_CHANNEL_TIMEOUT_MS_DEFAULT - Static variable in class com.google.cloud.bigtable.config.BigtableOptions
 
BIGTABLE_CLUSTER_ADMIN_HOST_DEFAULT - 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
 
BIGTABLE_DATA_HOST_DEFAULT - Static variable in class com.google.cloud.bigtable.config.BigtableOptions
 
BIGTABLE_TABLE_ADMIN_HOST_DEFAULT - Static variable in class com.google.cloud.bigtable.config.BigtableOptions
 
BIGTABLE_V1_CLUSTER_FMT - Static variable in class com.google.cloud.bigtable.grpc.BigtableClusterName
 
BigtableAsyncUtilities - Class in com.google.cloud.bigtable.grpc.async
Utilities for creating and executing async methods.
BigtableClusterAdminClient - Interface in com.google.cloud.bigtable.grpc
A client for the Cloud Bigtable Cluster Admin API.
BigtableClusterAdminGrpcClient - Class in com.google.cloud.bigtable.grpc
A gRPC client for accessing the Bigtable Cluster Admin API.
BigtableClusterAdminGrpcClient(Channel) - Constructor for class com.google.cloud.bigtable.grpc.BigtableClusterAdminGrpcClient
 
BigtableClusterName - Class in com.google.cloud.bigtable.grpc
This class encapsulates a Bigtable cluster name.
BigtableClusterName(String, String, String) - Constructor for class com.google.cloud.bigtable.grpc.BigtableClusterName
 
BigtableDataClient - Interface in com.google.cloud.bigtable.grpc
Interface to access v1 final Bigtable service methods
BigtableDataGrpcClient - Class in com.google.cloud.bigtable.grpc
A gRPC client to access the v1 Bigtable service.
BigtableDataGrpcClient(ChannelPool, ExecutorService, ScheduledExecutorService, RetryOptions) - Constructor for class com.google.cloud.bigtable.grpc.BigtableDataGrpcClient
 
BigtableOptions - Class in com.google.cloud.bigtable.config
An immutable class providing access to configuration options for Bigtable.
BigtableOptions.Builder - Class in com.google.cloud.bigtable.config
A mutable builder for BigtableConnectionOptions.
BigtableResultScannerFactory - 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.
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
 
BigtableSession(BigtableOptions, ExecutorService) - Constructor for class com.google.cloud.bigtable.grpc.BigtableSession
 
BigtableSession(BigtableOptions, ExecutorService, EventLoopGroup, ScheduledExecutorService) - Constructor for class com.google.cloud.bigtable.grpc.BigtableSession
 
BigtableTableAdminClient - Interface in com.google.cloud.bigtable.grpc
A client for the Cloud Bigtable Table Admin API.
BigtableTableAdminGrpcClient - Class in com.google.cloud.bigtable.grpc
A gRPC client for accessing the Bigtable Table Admin API.
BigtableTableAdminGrpcClient(Channel) - Constructor for class com.google.cloud.bigtable.grpc.BigtableTableAdminGrpcClient
 
BigtableTableName - Class in com.google.cloud.bigtable.grpc
This class encapsulates a tableName.
BigtableZeroCopyByteStringUtil - Class in com.google.protobuf
Helper class to extract byte arrays from ByteString without copy.
BigtableZeroCopyByteStringUtil() - Constructor for class com.google.protobuf.BigtableZeroCopyByteStringUtil
 
blockingServerStreamingCall(ClientCall<ReqT, RespT>, ReqT) - Method in interface com.google.cloud.bigtable.grpc.io.ClientCallService
 
blockingUnaryCall(ClientCall<ReqT, RespT>, ReqT) - Method in interface com.google.cloud.bigtable.grpc.io.ClientCallService
 
build() - Method in class com.google.cloud.bigtable.config.BigtableOptions.Builder
 
build() - Method in class com.google.cloud.bigtable.config.RetryOptions.Builder
Construct a new RetryOptions object.
Builder() - Constructor for class com.google.cloud.bigtable.config.BigtableOptions.Builder
 
Builder() - Constructor for class com.google.cloud.bigtable.config.RetryOptions.Builder
 
buildRow() - Method in class com.google.cloud.bigtable.grpc.scanner.RowMerger
Construct a row from previously seen partial rows.
ByteStringer - Class in com.google.cloud.bigtable.util
Wrapper around BigtableZeroCopyByteStringUtil for cases where it's not available.

C

call(BigtableDataClient, RequestT) - Method in interface com.google.cloud.bigtable.grpc.async.AsyncExecutor.AsyncCall
 
call(REQUEST) - Method in interface com.google.cloud.bigtable.grpc.async.RetryableRpc
 
cancel() - Method in class com.google.cloud.bigtable.grpc.io.CancellationToken
Inform listeners that the action has been / should be cancelled.
cancel() - Method in class com.google.cloud.bigtable.grpc.io.RetryingCall
 
CancellationToken - Class in com.google.cloud.bigtable.grpc.io
A class for communicating that an operation has been or should be cancelled.
CancellationToken() - Constructor for class com.google.cloud.bigtable.grpc.io.CancellationToken
 
CHANNEL_TERMINATE_WAIT_MS - Static variable in class com.google.cloud.bigtable.grpc.io.ReconnectingChannel
 
ChannelPool - Class in com.google.cloud.bigtable.grpc.io
Manages a set of ClosableChannels and uses them in a round robin.
ChannelPool(Channel[], List<HeaderInterceptor>) - Constructor for class com.google.cloud.bigtable.grpc.io.ChannelPool
 
ChannelPool.PooledChannel - Class in com.google.cloud.bigtable.grpc.io
An implementation of Channel that knows how to return itself to the ChannelPool
CHECK_AND_MUTATE_ASYNC - Static variable in class com.google.cloud.bigtable.grpc.async.AsyncExecutor
 
checkAndMutateRow(CheckAndMutateRowRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableDataClient
Mutate a row atomically dependant on a precondition.
checkAndMutateRow(CheckAndMutateRowRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGrpcClient
 
checkAndMutateRowAsync(CheckAndMutateRowRequest) - Method in class com.google.cloud.bigtable.grpc.async.AsyncExecutor
 
checkAndMutateRowAsync(CheckAndMutateRowRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableDataClient
Mutate a row atomically dependant on a precondition, returning a Future that will finish when the mutation has completed.
checkAndMutateRowAsync(CheckAndMutateRowRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGrpcClient
 
ClientCallService - Interface in com.google.cloud.bigtable.grpc.io
Wraps gRPC's ClientCall methods to allow for unit testing.
close() - Method in class com.google.cloud.bigtable.grpc.BigtableClusterAdminGrpcClient
 
close() - Method in class com.google.cloud.bigtable.grpc.BigtableSession
 
close() - Method in class com.google.cloud.bigtable.grpc.io.ReconnectingChannel
 
close() - Method in class com.google.cloud.bigtable.grpc.scanner.ResumingStreamingResultScanner
 
close() - Method in class com.google.cloud.bigtable.grpc.scanner.StreamingBigtableResultScanner
 
closeExecutor - Variable in class com.google.cloud.bigtable.grpc.io.ReconnectingChannel
 
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.
CollectingStreamObserver<T> - Class in com.google.cloud.bigtable.grpc.async
CollectingStreamObserver buffers all stream messages in an internal List and signals the result of CollectingStreamObserver.getResponseCompleteFuture() when complete.
CollectingStreamObserver() - Constructor for class com.google.cloud.bigtable.grpc.async.CollectingStreamObserver
 
com.google.cloud.bigtable.config - package com.google.cloud.bigtable.config
 
com.google.cloud.bigtable.grpc - package com.google.cloud.bigtable.grpc
 
com.google.cloud.bigtable.grpc.async - package com.google.cloud.bigtable.grpc.async
 
com.google.cloud.bigtable.grpc.io - package com.google.cloud.bigtable.grpc.io
 
com.google.cloud.bigtable.grpc.scanner - package com.google.cloud.bigtable.grpc.scanner
 
com.google.cloud.bigtable.util - package com.google.cloud.bigtable.util
 
com.google.protobuf - package com.google.protobuf
 
complete() - Method in class com.google.cloud.bigtable.grpc.scanner.StreamingBigtableResultScanner
 
create(RetryOptions, RequestT, RetryableRpc<RequestT, ResponseT>) - Static method in class com.google.cloud.bigtable.grpc.async.RetryingRpcFutureFallback
 
create(Throwable) - Method in class com.google.cloud.bigtable.grpc.async.RetryingRpcFutureFallback
 
createBackoff() - Method in class com.google.cloud.bigtable.config.RetryOptions
 
createBackoffBuilder() - Method in class com.google.cloud.bigtable.config.RetryOptions
 
createChannel(String, int) - Method in class com.google.cloud.bigtable.grpc.BigtableSession
Create a new Channel, with auth headers and user agent interceptors.
createChannel() - Method in interface com.google.cloud.bigtable.grpc.io.ReconnectingChannel.Factory
 
createClosable(Channel) - Method in interface com.google.cloud.bigtable.grpc.io.ReconnectingChannel.Factory
 
createCluster(CreateClusterRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableClusterAdminClient
Creates a cluster and begins preparing it to begin serving.
createCluster(CreateClusterRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableClusterAdminGrpcClient
 
createColumnFamily(CreateColumnFamilyRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableTableAdminClient
Creates a new column family within a specified table.
createColumnFamily(CreateColumnFamilyRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGrpcClient
 
createDefaultBatchPool() - Static method in class com.google.cloud.bigtable.grpc.BigtableSession
 
createDefaultEventLoopGroup() - Static method in class com.google.cloud.bigtable.grpc.BigtableSession
 
createDefaultRetryExecutor() - Static method in class com.google.cloud.bigtable.grpc.BigtableSession
 
createReconnectingChannel(InetSocketAddress) - Method in class com.google.cloud.bigtable.grpc.BigtableSession
 
createRowKeyAysncReader(Channel, ClientCallService) - Static method in class com.google.cloud.bigtable.grpc.async.BigtableAsyncUtilities
 
createSampleRowKeyAsyncReader(Channel, ClientCallService) - Static method in class com.google.cloud.bigtable.grpc.async.BigtableAsyncUtilities
 
createScanner(ReadRowsRequest) - Method in interface com.google.cloud.bigtable.grpc.scanner.BigtableResultScannerFactory
Create a scanner for the given request.
createTable(CreateTableRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableTableAdminClient
Creates a new table, to be served from a specified cluster.
createTable(CreateTableRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGrpcClient
 
credential(Credentials) - Static method in class com.google.cloud.bigtable.config.CredentialOptions
A CredentialOption that wraps an existing Credentials object.
CredentialFactory - Class in com.google.cloud.bigtable.config
Simple factory for creating OAuth Credential objects for use with Bigtable.
CredentialFactory() - Constructor for class com.google.cloud.bigtable.config.CredentialFactory
 
CredentialOptions - Class in com.google.cloud.bigtable.config
This class encapsulates the method the Cloud Bigtable client should use to look up Credentials.
CredentialOptions.CredentialType - Enum in com.google.cloud.bigtable.config
 
CredentialOptions.JsonCredentialsOptions - Class in com.google.cloud.bigtable.config
A CredentialOption that has a json credentials configured as an InputStream instead of a system environment property.
CredentialOptions.P12CredentialOptions - Class in com.google.cloud.bigtable.config
A CredentialOptions defined by a serviceAccount and a p12 key file.
CredentialOptions.UserSuppliedCredentialOptions - Class in com.google.cloud.bigtable.config
A CredentialOption that supplies the Credentials directly.

D

debug(String, Object...) - Method in class com.google.cloud.bigtable.config.Logger
 
DEFAULT - Static variable in interface com.google.cloud.bigtable.grpc.async.Sleeper
A Sleeper that uses Thread.sleep(long)
DEFAULT - Static variable in interface com.google.cloud.bigtable.grpc.io.ClientCallService
 
DEFAULT_BACKOFF_MULTIPLIER - Static variable in class com.google.cloud.bigtable.config.RetryOptions
Multiplier to apply to wait times after failed retries (default value: 2).
DEFAULT_BIGTABLE_PORT - Static variable in class com.google.cloud.bigtable.config.BigtableOptions
 
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_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_BATCH_SIZE - Static variable in class com.google.cloud.bigtable.config.RetryOptions
 
DEFAULT_STREAMING_BUFFER_SIZE - Static variable in class com.google.cloud.bigtable.config.RetryOptions
 
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.
deleteCluster(DeleteClusterRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableClusterAdminClient
Marks a cluster and all of its tables for permanent deletion in 7 days.
deleteCluster(DeleteClusterRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableClusterAdminGrpcClient
 
deleteColumnFamily(DeleteColumnFamilyRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableTableAdminClient
Permanently deletes a specified column family and all of its data.
deleteColumnFamily(DeleteColumnFamilyRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGrpcClient
 
deleteTable(DeleteTableRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableTableAdminClient
Permanently deletes a specified table and all of its data.
deleteTable(DeleteTableRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGrpcClient
 
doReadAsync(RetryOptions, RequestT, RetryableRpc<RequestT, ResponseT>, ExecutorService) - Static method in class com.google.cloud.bigtable.grpc.async.BigtableAsyncUtilities
Performs the rpc with retries.

E

ENABLE_GRPC_RETRIES_DEFAULT - Static variable in class com.google.cloud.bigtable.config.RetryOptions
Flag indicating whether or not grpc retries should be enabled.
ENABLE_GRPC_RETRY_DEADLINE_EXCEEDED_DEFAULT - Static variable in class com.google.cloud.bigtable.config.RetryOptions
Flag indicating whether or not to retry grpc call on deadline exceeded.
enableRetries() - Method in class com.google.cloud.bigtable.config.RetryOptions
Enable or disable retries.
error(String, Object...) - Method in class com.google.cloud.bigtable.config.Logger
 
error(String, Throwable, Object...) - Method in class com.google.cloud.bigtable.config.Logger
 
extract(ByteString) - Static method in class com.google.cloud.bigtable.util.ByteStringer
 

F

fatal(String, Object...) - Method in class com.google.cloud.bigtable.config.Logger
 
fatal(String, Throwable, Object...) - Method in class com.google.cloud.bigtable.config.Logger
 
flush() - Method in class com.google.cloud.bigtable.grpc.async.AsyncExecutor
 

G

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.
getBackoffMultiplier() - Method in class com.google.cloud.bigtable.config.RetryOptions
Multiplier we will apply to backoff times between retries.
getCachedCredentials() - Method in class com.google.cloud.bigtable.config.CredentialOptions.JsonCredentialsOptions
 
getChannelCount() - Method in class com.google.cloud.bigtable.config.BigtableOptions
The number of channels to create.
getCluster(GetClusterRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableClusterAdminClient
Gets information about a particular cluster.
getCluster(GetClusterRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableClusterAdminGrpcClient
 
getClusterAdminClient() - Method in class com.google.cloud.bigtable.grpc.BigtableSession
 
getClusterAdminHost() - Method in class com.google.cloud.bigtable.config.BigtableOptions
 
getClusterId() - Method in class com.google.cloud.bigtable.config.BigtableOptions
 
getClusterName() - Method in class com.google.cloud.bigtable.config.BigtableOptions
 
getCompletionFuture() - Method in class com.google.cloud.bigtable.grpc.async.AsyncUnaryOperationObserver
 
getCredential() - Method in class com.google.cloud.bigtable.config.CredentialOptions.UserSuppliedCredentialOptions
 
getCredentialFromMetadataServiceAccount() - Static method in class com.google.cloud.bigtable.config.CredentialFactory
Initializes OAuth2 credential using preconfigured ServiceAccount settings on the local GCE VM.
getCredentialFromPrivateKeyServiceAccount(String, String) - Static method in class com.google.cloud.bigtable.config.CredentialFactory
Initializes OAuth2 credential from a private keyfile, as described in OAuth2 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 OAuth2 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.
getCredentialType() - Method in class com.google.cloud.bigtable.config.CredentialOptions
 
getDataClient() - Method in class com.google.cloud.bigtable.grpc.BigtableSession
 
getDataHost() - Method in class com.google.cloud.bigtable.config.BigtableOptions
 
getEnvJsonFile() - Static method in class com.google.cloud.bigtable.config.CredentialOptions
Get a configured json credentials file from the GOOGLE_APPLICATION_CREDENTIALS environment variable.
getHttpTransport() - Static method in class com.google.cloud.bigtable.config.CredentialFactory
Returns shared httpTransport instance; initializes httpTransport if it hasn't already been initialized.
getInitialBackoffMillis() - Method in class com.google.cloud.bigtable.config.RetryOptions
The amount of time in miliiseconds 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.
getKeyFile() - Method in class com.google.cloud.bigtable.config.CredentialOptions.P12CredentialOptions
P12 file - https://developers.google.com/identity/protocols/OAuth2ServiceAccount
getMaxElaspedBackoffMillis() - Method in class com.google.cloud.bigtable.config.RetryOptions
Maximum amount of time we will retry an operation that is failing.
getMaxHeapSize() - Method in class com.google.cloud.bigtable.grpc.async.AsyncExecutor
 
getMaxHeapSize() - Method in class com.google.cloud.bigtable.grpc.async.HeapSizeManager
 
getNextMergedRow() - Method in class com.google.cloud.bigtable.grpc.scanner.ResponseQueueReader
Get the next complete Row object from the response queue.
getOperation(GetOperationRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableClusterAdminClient
Gets the latest state of a long-running operation.
getOperation(GetOperationRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableClusterAdminGrpcClient
 
getOverrideIp() - Method in class com.google.cloud.bigtable.config.BigtableOptions
Returns an override IP for all *Hosts.
getPort() - Method in class com.google.cloud.bigtable.config.BigtableOptions
 
getProjectId() - Method in class com.google.cloud.bigtable.config.BigtableOptions
 
getReadPartialRowTimeoutMillis() - Method in class com.google.cloud.bigtable.config.RetryOptions
A timeout for reading individual ReadRowsResponse messages from a stream.
getResponseCompleteFuture() - Method in class com.google.cloud.bigtable.grpc.async.CollectingStreamObserver
 
getRetryOptions() - Method in class com.google.cloud.bigtable.config.BigtableOptions
Options controlling retries.
getRetryState(BackOff) - Method in class com.google.cloud.bigtable.grpc.io.RefreshingOAuth2CredentialsInterceptor
Sleep and/or determine if the backoff has timed out.
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
getStatus() - Method in exception com.google.cloud.bigtable.grpc.io.IOExceptionWithStatus
Status from the provided OperationRuntimeException.
getStreamingBatchSize() - Method in class com.google.cloud.bigtable.config.RetryOptions
The number of messages to request when scanning.
getStreamingBufferSize() - Method in class com.google.cloud.bigtable.config.RetryOptions
The maximum number of messages to buffer when scanning.
getTable(GetTableRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableTableAdminClient
Gets the details of a table.
getTable(GetTableRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGrpcClient
 
getTableAdminClient() - Method in class com.google.cloud.bigtable.grpc.BigtableSession
 
getTableAdminHost() - Method in class com.google.cloud.bigtable.config.BigtableOptions
 
getTimeoutMs() - Method in class com.google.cloud.bigtable.config.BigtableOptions
The timeout for a channel.
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.
getZoneId() - Method in class com.google.cloud.bigtable.config.BigtableOptions
 
GRPC_EVENTLOOP_GROUP_NAME - Static variable in class com.google.cloud.bigtable.grpc.BigtableSession
 

H

halfClose() - Method in class com.google.cloud.bigtable.grpc.io.RetryingCall
 
hasInflightRequests() - Method in class com.google.cloud.bigtable.grpc.async.AsyncExecutor
 
hasInflightRequests() - Method in class com.google.cloud.bigtable.grpc.async.HeapSizeManager
 
HeaderInterceptor - Interface in com.google.cloud.bigtable.grpc.io
This interface provides a simple mechanism to update headers before a gRPC method is called.
HeapSizeManager - Class in com.google.cloud.bigtable.grpc.async
This class ensures that operations meet heap size and max RPC counts.
HeapSizeManager(long, int) - Constructor for class com.google.cloud.bigtable.grpc.async.HeapSizeManager
 

I

info(String, Object...) - Method in class com.google.cloud.bigtable.config.Logger
 
IOExceptionWithStatus - Exception in com.google.cloud.bigtable.grpc.io
An IOException that carries a gRPC Status object.
IOExceptionWithStatus(String, StatusRuntimeException) - Constructor for exception com.google.cloud.bigtable.grpc.io.IOExceptionWithStatus
 
IS_RETRYABLE_CHECK_AND_MUTATE - Static variable in class com.google.cloud.bigtable.grpc.BigtableDataGrpcClient
 
IS_RETRYABLE_MUTATION - Static variable in class com.google.cloud.bigtable.grpc.BigtableDataGrpcClient
 
isAlpnProviderEnabled() - Static method in class com.google.cloud.bigtable.grpc.BigtableSession
 
isFull() - Method in class com.google.cloud.bigtable.grpc.async.HeapSizeManager
 
isReady() - Method in class com.google.cloud.bigtable.grpc.io.RetryingCall
 
isRetryableRead(Status.Code) - Method in class com.google.cloud.bigtable.config.RetryOptions
 
isRowCommitted() - Method in class com.google.cloud.bigtable.grpc.scanner.RowMerger
Indicate whether a Chunk of type COMMIT_ROW been encountered.

J

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

L

listClusters(ListClustersRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableClusterAdminClient
Lists all clusters in the given project, along with any zones for which cluster information could not be retrieved.
listClusters(ListClustersRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableClusterAdminGrpcClient
 
listenableAsyncCall(ClientCall<ReqT, RespT>, ReqT) - Method in interface com.google.cloud.bigtable.grpc.io.ClientCallService
 
listTables(ListTablesRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableTableAdminClient
Lists the names of all tables served from a specified cluster.
listTables(ListTablesRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGrpcClient
 
listZones(ListZonesRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableClusterAdminClient
Lists the names of all zones for a given project.
listZones(ListZonesRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableClusterAdminGrpcClient
 
LOG - Static variable in class com.google.cloud.bigtable.config.CredentialOptions
 
log - Variable in class com.google.cloud.bigtable.config.Logger
 
LOG - Static variable in class com.google.cloud.bigtable.grpc.async.AsyncExecutor
 
LOG - Static variable in class com.google.cloud.bigtable.grpc.async.HeapSizeManager
 
LOG - Variable in class com.google.cloud.bigtable.grpc.async.RetryingRpcFutureFallback
 
log - Static variable in class com.google.cloud.bigtable.grpc.io.ChannelPool
 
log - Static variable in class com.google.cloud.bigtable.grpc.io.ReconnectingChannel
 
Logger - Class in com.google.cloud.bigtable.config
Wrapper around commons Log to conditionally format messages if a specified log level is enabled.
Logger(Class<?>) - Constructor for class com.google.cloud.bigtable.config.Logger
 

M

markCanBeCompleted(Long) - Method in class com.google.cloud.bigtable.grpc.async.HeapSizeManager
 
MAX_INFLIGHT_RPCS_DEFAULT - Static variable in class com.google.cloud.bigtable.grpc.async.AsyncExecutor
 
MUTATE_ASYNC - Static variable in class com.google.cloud.bigtable.grpc.async.AsyncExecutor
 
mutateRow(MutateRowRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableDataClient
Mutate a row atomically.
mutateRow(MutateRowRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGrpcClient
 
mutateRowAsync(MutateRowRequest) - Method in class com.google.cloud.bigtable.grpc.async.AsyncExecutor
 
mutateRowAsync(MutateRowRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableDataClient
Mutate a row atomically, returning a Future that will finish when the mutation has completed.
mutateRowAsync(MutateRowRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGrpcClient
 

N

newCall(MethodDescriptor<ReqT, RespT>, CallOptions) - Method in class com.google.cloud.bigtable.grpc.io.ChannelPool
 
newCall(MethodDescriptor<RequestT, ResponseT>, CallOptions) - Method in class com.google.cloud.bigtable.grpc.io.ChannelPool.PooledChannel
 
newCall(MethodDescriptor<RequestT, ResponseT>, CallOptions) - Method in class com.google.cloud.bigtable.grpc.io.ReconnectingChannel
 
next(int) - Method in class com.google.cloud.bigtable.grpc.scanner.AbstractBigtableResultScanner
 
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() - Method in class com.google.cloud.bigtable.grpc.scanner.ResumingStreamingResultScanner
 
next() - Method in class com.google.cloud.bigtable.grpc.scanner.StreamingBigtableResultScanner
 
nullCredential() - Static method in class com.google.cloud.bigtable.config.CredentialOptions
No credentials - used for unit testing.

O

onCompleted() - Method in class com.google.cloud.bigtable.grpc.async.AsyncUnaryOperationObserver
 
onCompleted() - Method in class com.google.cloud.bigtable.grpc.async.CollectingStreamObserver
 
onError(Throwable) - Method in class com.google.cloud.bigtable.grpc.async.AsyncUnaryOperationObserver
 
onError(Throwable) - Method in class com.google.cloud.bigtable.grpc.async.CollectingStreamObserver
 
onNext(T) - Method in class com.google.cloud.bigtable.grpc.async.AsyncUnaryOperationObserver
 
onNext(T) - Method in class com.google.cloud.bigtable.grpc.async.CollectingStreamObserver
 

P

p12Credential(String, String) - Static method in class com.google.cloud.bigtable.config.CredentialOptions
Initializes OAuth2 credential from a private keyfile, as described in OAuth2 Service Accounts

R

READ_MODIFY_WRITE_ASYNC - Static variable in class com.google.cloud.bigtable.grpc.async.AsyncExecutor
 
READ_ROWS_ASYNC - Static variable in class com.google.cloud.bigtable.grpc.async.AsyncExecutor
 
readModifyWriteRow(ReadModifyWriteRowRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableDataClient
Perform an atomic read-modify-write operation on a row.
readModifyWriteRow(ReadModifyWriteRowRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGrpcClient
 
readModifyWriteRowAsync(ReadModifyWriteRowRequest) - Method in class com.google.cloud.bigtable.grpc.async.AsyncExecutor
 
readModifyWriteRowAsync(ReadModifyWriteRowRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableDataClient
Perform an atomic read-modify-write operation on a row, returning a Future that will complete when the mutation has completed.
readModifyWriteRowAsync(ReadModifyWriteRowRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGrpcClient
 
readNextRow(Iterator<ReadRowsResponse>) - Static method in class com.google.cloud.bigtable.grpc.scanner.RowMerger
Reads the next Row from the responseIterator.
readRows(ReadRowsRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableDataClient
Perform a scan over rows.
readRows(ReadRowsRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGrpcClient
 
readRowsAsync(ReadRowsRequest) - Method in class com.google.cloud.bigtable.grpc.async.AsyncExecutor
 
readRowsAsync(ReadRowsRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableDataClient
Read multiple Rows into an in-memory list, returning a Future that will complete when the readRows call has completed.
readRowsAsync(ReadRowsRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGrpcClient
 
ReconnectingChannel - Class in com.google.cloud.bigtable.grpc.io
A ClosableChannel that refreshes itself based on a user supplied timeout.
ReconnectingChannel(long, ReconnectingChannel.Factory) - Constructor for class com.google.cloud.bigtable.grpc.io.ReconnectingChannel
 
ReconnectingChannel.Factory - Interface in com.google.cloud.bigtable.grpc.io
Creates a fresh CloseableChannel.
refreshCredentialsWithRetry() - Method in class com.google.cloud.bigtable.grpc.io.RefreshingOAuth2CredentialsInterceptor
Calls OAuth2Credentials.refreshAccessToken().
RefreshingOAuth2CredentialsInterceptor - Class in com.google.cloud.bigtable.grpc.io
Client interceptor that authenticates all calls by binding header data provided by a credential.
RefreshingOAuth2CredentialsInterceptor(ExecutorService, OAuth2Credentials, RetryOptions) - Constructor for class com.google.cloud.bigtable.grpc.io.RefreshingOAuth2CredentialsInterceptor
 
registerOperationWithHeapSize(long) - Method in class com.google.cloud.bigtable.grpc.async.HeapSizeManager
 
renameTable(RenameTableRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableTableAdminClient
Changes the name of a specified table.
renameTable(RenameTableRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableTableAdminGrpcClient
 
request(int) - Method in class com.google.cloud.bigtable.grpc.io.RetryingCall
 
reserveChannel() - Method in class com.google.cloud.bigtable.grpc.io.ChannelPool
Gets a channel from the pool.
ResponseQueueReader - Class in com.google.cloud.bigtable.grpc.scanner
Helper to read a queue of ResultQueueEntries and use the RowMergers to reconstruct complete Row objects from the partial ReadRowsResponse objects.
ResponseQueueReader(int, int, int, int, ClientCall<?, ReadRowsResponse>) - Constructor for class com.google.cloud.bigtable.grpc.scanner.ResponseQueueReader
 
ResultScanner<T> - Interface in com.google.cloud.bigtable.grpc.scanner
A scanner of Bigtable rows.
ResumingStreamingResultScanner - Class in com.google.cloud.bigtable.grpc.scanner
A ResultScanner that attempts to resume the readRows call when it encounters gRPC INTERNAL errors.
ResumingStreamingResultScanner(RetryOptions, ReadRowsRequest, BigtableResultScannerFactory) - Constructor for class com.google.cloud.bigtable.grpc.scanner.ResumingStreamingResultScanner
 
RETRY_THREAD_COUNT - Static variable in class com.google.cloud.bigtable.grpc.BigtableSession
Number of threads to use to initiate retry calls
RETRY_THREADPOOL_NAME - Static variable in class com.google.cloud.bigtable.grpc.BigtableSession
 
RetryableRpc<REQUEST,RESPONSE> - Interface in com.google.cloud.bigtable.grpc.async
This interface represents an RPC that is retryable.
RetryingCall<RequestT,ResponseT> - Class in com.google.cloud.bigtable.grpc.io
A Call that reties lower-level Calls that fail with INTERNAL errors.
RetryingCall(Channel, MethodDescriptor<RequestT, ResponseT>, CallOptions, ScheduledExecutorService, RetryOptions) - Constructor for class com.google.cloud.bigtable.grpc.io.RetryingCall
 
RetryingRpcFutureFallback<RequestT,ResponseT> - Class in com.google.cloud.bigtable.grpc.async
A FutureFallback that retries a RetryableRpc request.
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) - Constructor for class com.google.cloud.bigtable.config.RetryOptions
 
RetryOptions.Builder - Class in com.google.cloud.bigtable.config
A Builder for ChannelOptions objects.
returnToPool() - Method in class com.google.cloud.bigtable.grpc.io.ChannelPool.PooledChannel
 
RowMerger - Class in com.google.cloud.bigtable.grpc.scanner
Builds a complete Row from partial ReadRowsResponse objects.
RowMerger() - Constructor for class com.google.cloud.bigtable.grpc.scanner.RowMerger
 

S

sampleRowKeys(SampleRowKeysRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableDataClient
Sample row keys from a table.
sampleRowKeys(SampleRowKeysRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGrpcClient
 
sampleRowKeysAsync(SampleRowKeysRequest) - Method in interface com.google.cloud.bigtable.grpc.BigtableDataClient
Sample row keys from a table, returning a Future that will complete when the sampling has completed.
sampleRowKeysAsync(SampleRowKeysRequest) - Method in class com.google.cloud.bigtable.grpc.BigtableDataGrpcClient
 
ScanRetriesExhaustedException - Exception in com.google.cloud.bigtable.grpc.scanner
An Exception that is thrown when an operation fails, even in the face of retries.
ScanRetriesExhaustedException(String, Throwable) - Constructor for exception com.google.cloud.bigtable.grpc.scanner.ScanRetriesExhaustedException
 
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
 
sendMessage(RequestT) - Method in class com.google.cloud.bigtable.grpc.io.RetryingCall
 
SERVICE_ACCOUNT_JSON_ENV_VARIABLE - Static variable in class com.google.cloud.bigtable.config.CredentialOptions
 
setBackoffMultiplier(double) - Method in class com.google.cloud.bigtable.config.RetryOptions.Builder
Multiplier we will apply to backoff times between retries.
setCachedCredentails(Credentials) - Method in class com.google.cloud.bigtable.config.CredentialOptions.JsonCredentialsOptions
 
setClusterAdminHost(String) - Method in class com.google.cloud.bigtable.config.BigtableOptions.Builder
 
setClusterId(String) - Method in class com.google.cloud.bigtable.config.BigtableOptions.Builder
 
setCredentialOptions(CredentialOptions) - Method in class com.google.cloud.bigtable.config.BigtableOptions.Builder
 
setDataChannelCount(int) - Method in class com.google.cloud.bigtable.config.BigtableOptions.Builder
 
setDataHost(String) - Method in class com.google.cloud.bigtable.config.BigtableOptions.Builder
 
setEnableRetries(boolean) - Method in class com.google.cloud.bigtable.config.RetryOptions.Builder
Enable or disable retries.
setError(Throwable) - Method in class com.google.cloud.bigtable.grpc.scanner.StreamingBigtableResultScanner
 
setInitialBackoffMillis(int) - Method in class com.google.cloud.bigtable.config.RetryOptions.Builder
The amount of time in miliiseconds we will wait for our first error retry.
setMaxElapsedBackoffMillis(int) - Method in class com.google.cloud.bigtable.config.RetryOptions.Builder
Maximum amount of time we will retry an operation that is failing.
setOverrideIp(String) - Method in class com.google.cloud.bigtable.config.BigtableOptions.Builder
Override IP the for all *Hosts.
setPort(int) - Method in class com.google.cloud.bigtable.config.BigtableOptions.Builder
 
setProjectId(String) - Method in class com.google.cloud.bigtable.config.BigtableOptions.Builder
 
setReadPartialRowTimeoutMillis(int) - Method in class com.google.cloud.bigtable.config.RetryOptions.Builder
 
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
 
setStreamingBatchSize(int) - Method in class com.google.cloud.bigtable.config.RetryOptions.Builder
Set the number of messages to request when scanning.
setStreamingBufferSize(int) - Method in class com.google.cloud.bigtable.config.RetryOptions.Builder
Set the maximum number of messages to buffer when scanning.
setTableAdminHost(String) - Method in class com.google.cloud.bigtable.config.BigtableOptions.Builder
 
setTimeoutMs(int) - Method in class com.google.cloud.bigtable.config.BigtableOptions.Builder
 
setUserAgent(String) - Method in class com.google.cloud.bigtable.config.BigtableOptions.Builder
 
setZoneId(String) - Method in class com.google.cloud.bigtable.config.BigtableOptions.Builder
 
size() - Method in class com.google.cloud.bigtable.grpc.io.ChannelPool
 
sleep(long) - Method in interface com.google.cloud.bigtable.grpc.async.Sleeper
Usually a wrapper for Thread.sleep.
Sleeper - Interface in com.google.cloud.bigtable.grpc.async
An interface that wraps Thread.sleep for test purposes
start(ClientCall.Listener<ResponseT>, Metadata) - Method in class com.google.cloud.bigtable.grpc.io.RetryingCall
 
StreamingBigtableResultScanner - Class in com.google.cloud.bigtable.grpc.scanner
A ResultScanner implementation against the v1 bigtable API.
StreamingBigtableResultScanner(ResponseQueueReader, CancellationToken) - Constructor for class com.google.cloud.bigtable.grpc.scanner.StreamingBigtableResultScanner
 
syncRefresh() - Method in class com.google.cloud.bigtable.grpc.io.RefreshingOAuth2CredentialsInterceptor
 

T

TABLE_SEPARATOR - Static variable in class com.google.cloud.bigtable.grpc.BigtableClusterName
 
toString() - Method in class com.google.cloud.bigtable.grpc.BigtableClusterName
Get the cluster name.
toString() - Method in class com.google.cloud.bigtable.grpc.BigtableTableName
 
toTableId(String) - Method in class com.google.cloud.bigtable.grpc.BigtableClusterName
Transforms a tableName within this cluster of the form projects/(projectId)/zones/(zoneId)/clusters/(clusterId)/tables/(tableId) to (tableId).
toTableName(String) - Method in class com.google.cloud.bigtable.grpc.BigtableClusterName
 
toTableNameStr(String) - Method in class com.google.cloud.bigtable.grpc.BigtableClusterName
 
trace(String, Object...) - Method in class com.google.cloud.bigtable.config.Logger
 

U

updateCluster(Cluster) - Method in interface com.google.cloud.bigtable.grpc.BigtableClusterAdminClient
Updates a cluster, and begins allocating or releasing resources as requested.
updateCluster(Cluster) - Method in class com.google.cloud.bigtable.grpc.BigtableClusterAdminGrpcClient
 
updateHeaders(Metadata) - Method in interface com.google.cloud.bigtable.grpc.io.HeaderInterceptor
Modify the headers before an RPC call is made.
updateHeaders(Metadata) - Method in class com.google.cloud.bigtable.grpc.io.RefreshingOAuth2CredentialsInterceptor
 
updateHeaders(Metadata) - Method in class com.google.cloud.bigtable.grpc.io.UserAgentInterceptor
 
UserAgentInterceptor - Class in com.google.cloud.bigtable.grpc.io
An ClientInterceptor that updates "User-Agent" header.
UserAgentInterceptor(String) - Constructor for class com.google.cloud.bigtable.grpc.io.UserAgentInterceptor
 
UserSuppliedCredentialOptions(Credentials) - Constructor for class com.google.cloud.bigtable.config.CredentialOptions.UserSuppliedCredentialOptions
 

V

valueOf(String) - Static method in enum com.google.cloud.bigtable.config.CredentialOptions.CredentialType
Returns the enum constant of this type with the specified name.
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.

W

waitUntilAllOperationsAreDone() - Method in class com.google.cloud.bigtable.grpc.async.HeapSizeManager
 
warn(String, Object...) - Method in class com.google.cloud.bigtable.config.Logger
 
warn(String, Throwable, Object...) - Method in class com.google.cloud.bigtable.config.Logger
 
wrap(byte[]) - Static method in class com.google.cloud.bigtable.util.ByteStringer
Wraps a byte array in a ByteString without copying it.
wrap(byte[]) - Static method in class com.google.protobuf.BigtableZeroCopyByteStringUtil
Wraps a byte array in a ByteString without copying it.
wrap(byte[], int, int) - Static method in class com.google.protobuf.BigtableZeroCopyByteStringUtil
Wraps a subset of a byte array in a ByteString without copying it.

Z

zeroCopyGetBytes(ByteString) - Static method in class com.google.protobuf.BigtableZeroCopyByteStringUtil
Extracts the byte array from the given ByteString without copy.
A B C D E F G H I J L M N O P R S T U V W Z 
Skip navigation links

Copyright © 2015. All rights reserved.