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

A

abortBatch() - Method in interface com.google.cloud.spanner.connection.Connection
Clears all buffered statements in the current batch and ends the batch.
AbortedDueToConcurrentModificationException - Exception in com.google.cloud.spanner
Exception thrown by a Connection when a database operation detects that a transaction has aborted and an internal retry failed because of a concurrent modification.
AbortedException - Exception in com.google.cloud.spanner
Exception thrown by Cloud Spanner when an operation detects that a transaction has aborted.
AbstractLazyInitializer<T> - Class in com.google.cloud.spanner
Generic AbstractLazyInitializer for any heavy-weight object that might throw an exception during initialization.
AbstractLazyInitializer() - Constructor for class com.google.cloud.spanner.AbstractLazyInitializer
 
AbstractStructReader - Class in com.google.cloud.spanner
Base class for assisting StructReader implementations.
AbstractStructReader() - Constructor for class com.google.cloud.spanner.AbstractStructReader
 
add(Value) - Method in class com.google.cloud.spanner.Struct.Builder
Adds a new unnamed field fieldName with the given value.
addKey(Key) - Method in class com.google.cloud.spanner.KeySet.Builder
Adds a key to the key set.
addLabel(String, String) - Method in class com.google.cloud.spanner.Instance.Builder
 
addLabel(String, String) - Method in class com.google.cloud.spanner.InstanceInfo.Builder
 
addRange(KeyRange) - Method in class com.google.cloud.spanner.KeySet.Builder
Adds a range to the key set.
addTransactionRetryListener(TransactionRetryListener) - Method in interface com.google.cloud.spanner.connection.Connection
Add a TransactionRetryListener to this Connection for testing and logging purposes.
AdminRequestsPerMinuteExceededException - Exception in com.google.cloud.spanner
Exception thrown by Cloud Spanner the number of administrative requests per minute has been exceeded.
all() - Static method in class com.google.cloud.spanner.KeySet
Creates a key set that will retrieve all rows of a table or index.
allowNestedTransaction() - Method in interface com.google.cloud.spanner.TransactionRunner
Allows overriding the default behaviour of blocking nested transactions.
analyzeQuery(Statement, ReadContext.QueryAnalyzeMode) - Method in interface com.google.cloud.spanner.connection.Connection
Analyzes a query and returns query plan and/or query execution statistics information.
analyzeQuery(Statement, ReadContext.QueryAnalyzeMode) - Method in interface com.google.cloud.spanner.ReadContext
Analyzes a query and returns query plan and/or query execution statistics information.
analyzeQuery(ReadContext, ReadContext.QueryAnalyzeMode) - Method in class com.google.cloud.spanner.Statement
Analyzes the query in context.
append(Boolean) - Method in class com.google.cloud.spanner.Key.Builder
Appends a BOOL value to the key.
append(long) - Method in class com.google.cloud.spanner.Key.Builder
Appends an INT64 value to the key.
append(Long) - Method in class com.google.cloud.spanner.Key.Builder
Appends an INT64 value to the key.
append(double) - Method in class com.google.cloud.spanner.Key.Builder
Appends a FLOAT64 value to the key.
append(Double) - Method in class com.google.cloud.spanner.Key.Builder
Appends a FLOAT64 value to the key.
append(BigDecimal) - Method in class com.google.cloud.spanner.Key.Builder
Appends a NUMERIC value to the key.
append(String) - Method in class com.google.cloud.spanner.Key.Builder
Appends a STRING value to the key.
append(ByteArray) - Method in class com.google.cloud.spanner.Key.Builder
Appends a BYTES value to the key.
append(Timestamp) - Method in class com.google.cloud.spanner.Key.Builder
Appends a TIMESTAMP value to the key
append(Date) - Method in class com.google.cloud.spanner.Key.Builder
Appends a DATE value to the key
append(String) - Method in class com.google.cloud.spanner.Statement.Builder
Appends sqlFragment to the statement.
appendObject(Object) - Method in class com.google.cloud.spanner.Key.Builder
Appends an object following the same conversion rules as Key.of(Object...).
apply(TransactionContext, I) - Method in interface com.google.cloud.spanner.AsyncTransactionManager.AsyncTransactionFunction
apply(Throwable) - Method in class com.google.cloud.spanner.IsRetryableInternalError
 
apply(Throwable) - Method in class com.google.cloud.spanner.IsSslHandshakeException
 
applyToAllUnaryMethods(ApiFunction<UnaryCallSettings.Builder<?, ?>, Void>) - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminSettings.Builder
Applies the given settings updater function to all of the unary API methods in this service.
applyToAllUnaryMethods(ApiFunction<UnaryCallSettings.Builder<?, ?>, Void>) - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStubSettings.Builder
Applies the given settings updater function to all of the unary API methods in this service.
applyToAllUnaryMethods(ApiFunction<UnaryCallSettings.Builder<?, ?>, Void>) - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminSettings.Builder
Applies the given settings updater function to all of the unary API methods in this service.
applyToAllUnaryMethods(ApiFunction<UnaryCallSettings.Builder<?, ?>, Void>) - Method in class com.google.cloud.spanner.admin.instance.v1.stub.InstanceAdminStubSettings.Builder
Applies the given settings updater function to all of the unary API methods in this service.
applyToAllUnaryMethods(ApiFunction<UnaryCallSettings.Builder<?, ?>, Void>) - Method in class com.google.cloud.spanner.v1.SpannerSettings.Builder
Applies the given settings updater function to all of the unary API methods in this service.
applyToAllUnaryMethods(ApiFunction<UnaryCallSettings.Builder<?, ?>, Void>) - Method in class com.google.cloud.spanner.v1.stub.SpannerStubSettings.Builder
Applies the given settings updater function to all of the unary API methods in this service.
array(Type) - Static method in class com.google.cloud.spanner.Type
Returns a descriptor for an array of elementType.
asMap() - Method in class com.google.cloud.spanner.Mutation
For all types except Mutation.Op.DELETE, constructs a map from column name to value.
asSpannerException(Throwable) - Static method in class com.google.cloud.spanner.SpannerExceptionFactory
Converts the given Throwable to a SpannerException.
asyncClose() - Method in interface com.google.cloud.spanner.Session
Closes the session asynchronously and returns the ApiFuture that can be used to monitor the operation progress.
asyncDeleteSession(String, Map<SpannerRpc.Option, ?>) - Method in class com.google.cloud.spanner.spi.v1.GapicSpannerRpc
 
asyncDeleteSession(String, Map<SpannerRpc.Option, ?>) - Method in interface com.google.cloud.spanner.spi.v1.SpannerRpc
 
AsyncResultSet - Interface in com.google.cloud.spanner
Interface for result sets returned by async query methods.
AsyncResultSet.CallbackResponse - Enum in com.google.cloud.spanner
 
AsyncResultSet.CursorState - Enum in com.google.cloud.spanner
Response code from tryNext().
AsyncResultSet.ReadyCallback - Interface in com.google.cloud.spanner
Interface for receiving asynchronous callbacks when new data is ready.
AsyncRunner - Interface in com.google.cloud.spanner
 
AsyncRunner.AsyncWork<R> - Interface in com.google.cloud.spanner
Functional interface for executing a read/write transaction asynchronously that returns a result of type R.
AsyncStatementResult - Interface in com.google.cloud.spanner.connection
 
AsyncTransactionManager - Interface in com.google.cloud.spanner
An interface for managing the life cycle of a read write transaction including all its retries.
AsyncTransactionManager.AsyncTransactionFunction<I,O> - Interface in com.google.cloud.spanner
Each step in a transaction chain is defined by an AsyncTransactionManager.AsyncTransactionFunction.
AsyncTransactionManager.AsyncTransactionStep<I,O> - Interface in com.google.cloud.spanner
AsyncTransactionManager.AsyncTransactionStep is returned by TransactionContextFuture#then(AsyncTransactionFunction) and AsyncTransactionStep#then(AsyncTransactionFunction) and allows transaction steps that should be executed serially to be chained together.
AsyncTransactionManager.CommitTimestampFuture - Interface in com.google.cloud.spanner
ApiFuture that returns the commit Timestamp of a Cloud Spanner transaction that is executed using an AsyncTransactionManager.
AsyncTransactionManager.TransactionContextFuture - Interface in com.google.cloud.spanner
ApiFuture that returns a TransactionContext and that supports chaining of multiple AsyncTransactionManager.TransactionContextFutures to form a transaction.
AUTOCOMMIT_PROPERTY_NAME - Static variable in class com.google.cloud.spanner.connection.ConnectionOptions
Name of the 'autocommit' connection property.
AutocommitDmlMode - Enum in com.google.cloud.spanner.connection
Enum used to define the behavior of DML statements in autocommit mode
awaitTermination(long, TimeUnit) - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
 
awaitTermination(long, TimeUnit) - Method in class com.google.cloud.spanner.admin.database.v1.stub.GrpcDatabaseAdminStub
 
awaitTermination(long, TimeUnit) - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminClient
 
awaitTermination(long, TimeUnit) - Method in class com.google.cloud.spanner.admin.instance.v1.stub.GrpcInstanceAdminStub
 
awaitTermination(long, TimeUnit) - Method in class com.google.cloud.spanner.v1.SpannerClient
 
awaitTermination(long, TimeUnit) - Method in class com.google.cloud.spanner.v1.stub.GrpcSpannerStub
 

B

Backup - Class in com.google.cloud.spanner
Represents a Cloud Spanner database backup.
backup(Backup) - Method in class com.google.cloud.spanner.Database
Backs up this database to the location specified by the Backup.
Backup.Builder - Class in com.google.cloud.spanner
 
BackupId - Class in com.google.cloud.spanner
Represents an id of a Cloud Spanner backup resource.
BackupInfo - Class in com.google.cloud.spanner
Represents a Cloud Spanner database backup.
BackupInfo.Builder - Class in com.google.cloud.spanner
 
BackupInfo.State - Enum in com.google.cloud.spanner
State of the backup.
BatchClient - Interface in com.google.cloud.spanner
Interface for the Batch Client that is used to read data from a Cloud Spanner database.
BatchClientImpl - Class in com.google.cloud.spanner
Default implementation for Batch Client interface.
batchCreateSessions(String, int, Map<String, String>, Map<SpannerRpc.Option, ?>) - Method in class com.google.cloud.spanner.spi.v1.GapicSpannerRpc
 
batchCreateSessions(String, int, Map<String, String>, Map<SpannerRpc.Option, ?>) - Method in interface com.google.cloud.spanner.spi.v1.SpannerRpc
 
batchCreateSessions(DatabaseName, int) - Method in class com.google.cloud.spanner.v1.SpannerClient
Creates multiple new sessions.
batchCreateSessions(String, int) - Method in class com.google.cloud.spanner.v1.SpannerClient
Creates multiple new sessions.
batchCreateSessions(BatchCreateSessionsRequest) - Method in class com.google.cloud.spanner.v1.SpannerClient
Creates multiple new sessions.
batchCreateSessionsCallable() - Method in class com.google.cloud.spanner.v1.SpannerClient
Creates multiple new sessions.
batchCreateSessionsCallable() - Method in class com.google.cloud.spanner.v1.stub.GrpcSpannerStub
 
batchCreateSessionsCallable() - Method in class com.google.cloud.spanner.v1.stub.SpannerStub
 
batchCreateSessionsSettings() - Method in class com.google.cloud.spanner.v1.SpannerSettings
Returns the object with the settings used for calls to batchCreateSessions.
batchCreateSessionsSettings() - Method in class com.google.cloud.spanner.v1.SpannerSettings.Builder
Returns the builder for the settings used for calls to batchCreateSessions.
batchCreateSessionsSettings() - Method in class com.google.cloud.spanner.v1.stub.SpannerStubSettings
Returns the object with the settings used for calls to batchCreateSessions.
batchCreateSessionsSettings() - Method in class com.google.cloud.spanner.v1.stub.SpannerStubSettings.Builder
Returns the builder for the settings used for calls to batchCreateSessions.
batchReadOnlyTransaction(TimestampBound) - Method in interface com.google.cloud.spanner.BatchClient
Returns a BatchReadOnlyTransaction context in which multiple reads and/or queries can be performed.
batchReadOnlyTransaction(BatchTransactionId) - Method in interface com.google.cloud.spanner.BatchClient
Returns a BatchReadOnlyTransaction context in which multiple reads and/or queries can be performed.
batchReadOnlyTransaction(TimestampBound) - Method in class com.google.cloud.spanner.BatchClientImpl
 
batchReadOnlyTransaction(BatchTransactionId) - Method in class com.google.cloud.spanner.BatchClientImpl
 
BatchReadOnlyTransaction - Interface in com.google.cloud.spanner
BatchReadOnlyTransaction can be configured to read at timestamps in the past and allows for exporting arbitrarily large amounts of data from Cloud Spanner databases.
BatchTransactionId - Class in com.google.cloud.spanner
BatchTransactionId is unique identifier for BatchReadOnlyTransaction.
batchUpdate(Iterable<Statement>, Options.UpdateOption...) - Method in interface com.google.cloud.spanner.TransactionContext
Executes a list of DML statements in a single request.
batchUpdateAsync(Iterable<Statement>, Options.UpdateOption...) - Method in interface com.google.cloud.spanner.TransactionContext
Same as #batchUpdate(Iterable), but is guaranteed to be non-blocking.
begin() - Method in interface com.google.cloud.spanner.TransactionManager
Creates a new read write transaction.
beginAsync() - Method in interface com.google.cloud.spanner.AsyncTransactionManager
Creates a new read write transaction.
beginTransaction() - Method in interface com.google.cloud.spanner.connection.Connection
Begins a new transaction for this connection.
beginTransaction(BeginTransactionRequest, Map<SpannerRpc.Option, ?>) - Method in class com.google.cloud.spanner.spi.v1.GapicSpannerRpc
 
beginTransaction(BeginTransactionRequest, Map<SpannerRpc.Option, ?>) - Method in interface com.google.cloud.spanner.spi.v1.SpannerRpc
 
beginTransaction(SessionName, TransactionOptions) - Method in class com.google.cloud.spanner.v1.SpannerClient
Begins a new transaction.
beginTransaction(String, TransactionOptions) - Method in class com.google.cloud.spanner.v1.SpannerClient
Begins a new transaction.
beginTransaction(BeginTransactionRequest) - Method in class com.google.cloud.spanner.v1.SpannerClient
Begins a new transaction.
beginTransactionAsync() - Method in interface com.google.cloud.spanner.connection.Connection
Begins a new transaction for this connection.
beginTransactionAsync(BeginTransactionRequest, Map<SpannerRpc.Option, ?>) - Method in class com.google.cloud.spanner.spi.v1.GapicSpannerRpc
 
beginTransactionAsync(BeginTransactionRequest, Map<SpannerRpc.Option, ?>) - Method in interface com.google.cloud.spanner.spi.v1.SpannerRpc
 
beginTransactionCallable() - Method in class com.google.cloud.spanner.v1.SpannerClient
Begins a new transaction.
beginTransactionCallable() - Method in class com.google.cloud.spanner.v1.stub.GrpcSpannerStub
 
beginTransactionCallable() - Method in class com.google.cloud.spanner.v1.stub.SpannerStub
 
beginTransactionSettings() - Method in class com.google.cloud.spanner.v1.SpannerSettings
Returns the object with the settings used for calls to beginTransaction.
beginTransactionSettings() - Method in class com.google.cloud.spanner.v1.SpannerSettings.Builder
Returns the builder for the settings used for calls to beginTransaction.
beginTransactionSettings() - Method in class com.google.cloud.spanner.v1.stub.SpannerStubSettings
Returns the object with the settings used for calls to beginTransaction.
beginTransactionSettings() - Method in class com.google.cloud.spanner.v1.stub.SpannerStubSettings.Builder
Returns the builder for the settings used for calls to beginTransaction.
bind(String) - Method in class com.google.cloud.spanner.Statement.Builder
Returns a binder to bind the value of the query parameter parameter.
bool() - Static method in class com.google.cloud.spanner.Type
Returns the descriptor for the BOOL type.
bool(Boolean) - Static method in class com.google.cloud.spanner.Value
Returns a BOOL value.
bool(boolean) - Static method in class com.google.cloud.spanner.Value
Returns a BOOL value.
boolArray(boolean[]) - Static method in class com.google.cloud.spanner.Value
Returns an ARRAY<BOOL> value.
boolArray(boolean[], int, int) - Static method in class com.google.cloud.spanner.Value
Returns an ARRAY<BOOL> value that takes its elements from a region of an array.
boolArray(Iterable<Boolean>) - Static method in class com.google.cloud.spanner.Value
Returns an ARRAY<BOOL> value.
buffer(Mutation) - Method in interface com.google.cloud.spanner.TransactionContext
Buffers a single mutation to be applied if the transaction commits successfully.
buffer(Iterable<Mutation>) - Method in interface com.google.cloud.spanner.TransactionContext
Buffers mutations to be applied if the transaction commits successfully.
bufferedWrite(Mutation) - Method in interface com.google.cloud.spanner.connection.Connection
Buffers the given mutation locally on the current transaction of this Connection.
bufferedWrite(Iterable<Mutation>) - Method in interface com.google.cloud.spanner.connection.Connection
Buffers the given mutations locally on the current transaction of this Connection.
bufferRows(int) - Static method in class com.google.cloud.spanner.Options
 
build() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminSettings.Builder
 
build() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStubSettings.Builder
 
build() - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminSettings.Builder
 
build() - Method in class com.google.cloud.spanner.admin.instance.v1.stub.InstanceAdminStubSettings.Builder
 
build() - Method in class com.google.cloud.spanner.Backup.Builder
 
build() - Method in class com.google.cloud.spanner.BackupInfo.Builder
Builds the backup from this builder.
build() - Method in class com.google.cloud.spanner.connection.ConnectionOptions.Builder
 
build() - Method in class com.google.cloud.spanner.Database.Builder
 
build() - Method in class com.google.cloud.spanner.DatabaseInfo.Builder
Builds the database from this builder.
build() - Method in class com.google.cloud.spanner.Instance.Builder
 
build() - Method in class com.google.cloud.spanner.InstanceInfo.Builder
 
build() - Method in class com.google.cloud.spanner.Key.Builder
 
build() - Method in class com.google.cloud.spanner.KeyRange.Builder
 
build() - Method in class com.google.cloud.spanner.KeySet.Builder
 
build() - Method in class com.google.cloud.spanner.Mutation.WriteBuilder
Returns a newly created Mutation based on the contents of the Builder.
build() - Method in class com.google.cloud.spanner.PartitionOptions.Builder
 
build() - Method in class com.google.cloud.spanner.SessionPoolOptions.Builder
Build a SessionPoolOption object
build() - Method in class com.google.cloud.spanner.SpannerOptions.Builder
 
build() - Method in class com.google.cloud.spanner.Statement.Builder
Builds the Statement.
build() - Method in class com.google.cloud.spanner.Struct.Builder
 
build() - Method in class com.google.cloud.spanner.v1.SpannerSettings.Builder
 
build() - Method in class com.google.cloud.spanner.v1.stub.SpannerStubSettings.Builder
 
Builder() - Constructor for class com.google.cloud.spanner.admin.database.v1.DatabaseAdminSettings.Builder
 
Builder(ClientContext) - Constructor for class com.google.cloud.spanner.admin.database.v1.DatabaseAdminSettings.Builder
 
Builder(DatabaseAdminSettings) - Constructor for class com.google.cloud.spanner.admin.database.v1.DatabaseAdminSettings.Builder
 
Builder(DatabaseAdminStubSettings.Builder) - Constructor for class com.google.cloud.spanner.admin.database.v1.DatabaseAdminSettings.Builder
 
Builder() - Constructor for class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStubSettings.Builder
 
Builder(ClientContext) - Constructor for class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStubSettings.Builder
 
Builder(DatabaseAdminStubSettings) - Constructor for class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStubSettings.Builder
 
Builder() - Constructor for class com.google.cloud.spanner.admin.instance.v1.InstanceAdminSettings.Builder
 
Builder(ClientContext) - Constructor for class com.google.cloud.spanner.admin.instance.v1.InstanceAdminSettings.Builder
 
Builder(InstanceAdminSettings) - Constructor for class com.google.cloud.spanner.admin.instance.v1.InstanceAdminSettings.Builder
 
Builder(InstanceAdminStubSettings.Builder) - Constructor for class com.google.cloud.spanner.admin.instance.v1.InstanceAdminSettings.Builder
 
Builder() - Constructor for class com.google.cloud.spanner.admin.instance.v1.stub.InstanceAdminStubSettings.Builder
 
Builder(ClientContext) - Constructor for class com.google.cloud.spanner.admin.instance.v1.stub.InstanceAdminStubSettings.Builder
 
Builder(InstanceAdminStubSettings) - Constructor for class com.google.cloud.spanner.admin.instance.v1.stub.InstanceAdminStubSettings.Builder
 
Builder() - Constructor for class com.google.cloud.spanner.BackupInfo.Builder
 
Builder() - Constructor for class com.google.cloud.spanner.DatabaseInfo.Builder
 
Builder() - Constructor for class com.google.cloud.spanner.InstanceInfo.Builder
 
Builder() - Constructor for class com.google.cloud.spanner.SessionPoolOptions.Builder
 
Builder() - Constructor for class com.google.cloud.spanner.v1.SpannerSettings.Builder
 
Builder(ClientContext) - Constructor for class com.google.cloud.spanner.v1.SpannerSettings.Builder
 
Builder(SpannerSettings) - Constructor for class com.google.cloud.spanner.v1.SpannerSettings.Builder
 
Builder(SpannerStubSettings.Builder) - Constructor for class com.google.cloud.spanner.v1.SpannerSettings.Builder
 
Builder() - Constructor for class com.google.cloud.spanner.v1.stub.SpannerStubSettings.Builder
 
Builder(ClientContext) - Constructor for class com.google.cloud.spanner.v1.stub.SpannerStubSettings.Builder
 
Builder(SpannerStubSettings) - Constructor for class com.google.cloud.spanner.v1.stub.SpannerStubSettings.Builder
 
bytes() - Static method in class com.google.cloud.spanner.Type
Returns the descriptor for the BYTES type: a variable-length byte string.
bytes(ByteArray) - Static method in class com.google.cloud.spanner.Value
Returns a BYTES value.
bytesArray(Iterable<ByteArray>) - Static method in class com.google.cloud.spanner.Value
Returns an ARRAY<BYTES> value.

C

CALL_CONTEXT_CONFIGURATOR_KEY - Static variable in class com.google.cloud.spanner.SpannerOptions
Context key for the SpannerOptions.CallContextConfigurator to use.
cancel() - Method in interface com.google.cloud.spanner.AsyncResultSet
Attempt to cancel this operation and free all resources.
cancel() - Method in interface com.google.cloud.spanner.connection.Connection
Cancels the currently running statement on this Connection (if any).
cancel() - Method in class com.google.cloud.spanner.ForwardingAsyncResultSet
 
cancel(String) - Method in interface com.google.cloud.spanner.spi.v1.SpannerRpc.StreamingCall
Cancels the call.
cancelOperation(String) - Method in interface com.google.cloud.spanner.DatabaseAdminClient
Cancels the specified long-running operation.
cancelOperation(String) - Method in interface com.google.cloud.spanner.InstanceAdminClient
Cancels the specified long-running operation.
cancelOperation(String) - Method in class com.google.cloud.spanner.spi.v1.GapicSpannerRpc
 
cancelOperation(String) - Method in interface com.google.cloud.spanner.spi.v1.SpannerRpc
Cancels the specified long-running operation.
checkNonNull(int, Object) - Method in class com.google.cloud.spanner.AbstractStructReader
 
checkValidState() - Method in class com.google.cloud.spanner.ForwardingStructReader
Called before each forwarding call to allow sub classes to do additional state checking.
cleanUp() - Method in class com.google.cloud.spanner.testing.RemoteSpannerHelper
Deletes all the databases created via createTestDatabase.
clearStatementTimeout() - Method in interface com.google.cloud.spanner.connection.Connection
Clears the statement timeout value for this connection.
close() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
 
close() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStub
 
close() - Method in class com.google.cloud.spanner.admin.database.v1.stub.GrpcDatabaseAdminStub
 
close() - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminClient
 
close() - Method in class com.google.cloud.spanner.admin.instance.v1.stub.GrpcInstanceAdminStub
 
close() - Method in class com.google.cloud.spanner.admin.instance.v1.stub.InstanceAdminStub
 
close() - Method in interface com.google.cloud.spanner.AsyncTransactionManager
Closes the manager.
close() - Method in interface com.google.cloud.spanner.connection.Connection
Closes this connection.
close() - Method in class com.google.cloud.spanner.ForwardingResultSet
 
close() - Method in interface com.google.cloud.spanner.ReadContext
Closes this read context and frees up the underlying resources.
close() - Method in interface com.google.cloud.spanner.ResultSet
Explicitly close the result set, releasing any associated resources.
close() - Method in interface com.google.cloud.spanner.Session
 
close() - Method in interface com.google.cloud.spanner.Spanner
Closes all the clients associated with this instance and frees up all the resources.
close() - Method in interface com.google.cloud.spanner.TransactionManager
Closes the manager.
close() - Method in class com.google.cloud.spanner.v1.SpannerClient
 
close() - Method in class com.google.cloud.spanner.v1.stub.GrpcSpannerStub
 
close() - Method in class com.google.cloud.spanner.v1.stub.SpannerStub
 
closeAsync() - Method in interface com.google.cloud.spanner.AsyncTransactionManager
Closes the transaction manager.
closedClosed(Key, Key) - Static method in class com.google.cloud.spanner.KeyRange
Returns a key range from start inclusive to end inclusive.
closedOpen(Key, Key) - Static method in class com.google.cloud.spanner.KeyRange
Returns a key range from start inclusive to end exclusive.
closeSpanner() - Static method in class com.google.cloud.spanner.connection.ConnectionOptions
Closes all Spanner instances that have been opened by connections during the lifetime of this JVM.
closeSpannerPool() - Static method in class com.google.cloud.spanner.connection.SpannerPool
Closes the default SpannerPool and all Spanner instances that have been opened by connections and that are still open.
com.google.cloud.spanner - package com.google.cloud.spanner
A client for Cloud Spanner - A no-compromise relational database service.
com.google.cloud.spanner.admin.database.v1 - package com.google.cloud.spanner.admin.database.v1
The interfaces provided are listed below, along with usage samples.
com.google.cloud.spanner.admin.database.v1.stub - package com.google.cloud.spanner.admin.database.v1.stub
 
com.google.cloud.spanner.admin.instance.v1 - package com.google.cloud.spanner.admin.instance.v1
The interfaces provided are listed below, along with usage samples.
com.google.cloud.spanner.admin.instance.v1.stub - package com.google.cloud.spanner.admin.instance.v1.stub
 
com.google.cloud.spanner.connection - package com.google.cloud.spanner.connection
Internal API for Google Cloud Spanner.
com.google.cloud.spanner.spi - package com.google.cloud.spanner.spi
 
com.google.cloud.spanner.spi.v1 - package com.google.cloud.spanner.spi.v1
 
com.google.cloud.spanner.testing - package com.google.cloud.spanner.testing
 
com.google.cloud.spanner.v1 - package com.google.cloud.spanner.v1
The interfaces provided are listed below, along with usage samples.
com.google.cloud.spanner.v1.stub - package com.google.cloud.spanner.v1.stub
 
commit() - Method in interface com.google.cloud.spanner.connection.Connection
Commits the current transaction of this connection.
commit(CommitRequest, Map<SpannerRpc.Option, ?>) - Method in class com.google.cloud.spanner.spi.v1.GapicSpannerRpc
 
commit(CommitRequest, Map<SpannerRpc.Option, ?>) - Method in interface com.google.cloud.spanner.spi.v1.SpannerRpc
 
commit() - Method in interface com.google.cloud.spanner.TransactionManager
Commits the currently active transaction.
commit(SessionName, ByteString, List<Mutation>) - Method in class com.google.cloud.spanner.v1.SpannerClient
Commits a transaction.
commit(SessionName, TransactionOptions, List<Mutation>) - Method in class com.google.cloud.spanner.v1.SpannerClient
Commits a transaction.
commit(String, ByteString, List<Mutation>) - Method in class com.google.cloud.spanner.v1.SpannerClient
Commits a transaction.
commit(String, TransactionOptions, List<Mutation>) - Method in class com.google.cloud.spanner.v1.SpannerClient
Commits a transaction.
commit(CommitRequest) - Method in class com.google.cloud.spanner.v1.SpannerClient
Commits a transaction.
COMMIT_TIMESTAMP - Static variable in class com.google.cloud.spanner.Value
Placeholder value to be passed to a mutation to make Cloud Spanner store the commit timestamp in that column.
commitAsync() - Method in interface com.google.cloud.spanner.AsyncTransactionManager.AsyncTransactionStep
Commits the transaction and returns a AsyncTransactionManager.CommitTimestampFuture that will return the commit timestamp of the transaction, or throw the first uncaught exception in the transaction chain as an ExecutionException.
commitAsync() - Method in interface com.google.cloud.spanner.connection.Connection
Commits the current transaction of this connection.
commitAsync(CommitRequest, Map<SpannerRpc.Option, ?>) - Method in class com.google.cloud.spanner.spi.v1.GapicSpannerRpc
 
commitAsync(CommitRequest, Map<SpannerRpc.Option, ?>) - Method in interface com.google.cloud.spanner.spi.v1.SpannerRpc
 
commitCallable() - Method in class com.google.cloud.spanner.v1.SpannerClient
Commits a transaction.
commitCallable() - Method in class com.google.cloud.spanner.v1.stub.GrpcSpannerStub
 
commitCallable() - Method in class com.google.cloud.spanner.v1.stub.SpannerStub
 
CommitResponse - Class in com.google.cloud.spanner
Represents a response from a commit operation.
CommitResponse(Timestamp) - Constructor for class com.google.cloud.spanner.CommitResponse
 
commitSettings() - Method in class com.google.cloud.spanner.v1.SpannerSettings.Builder
Returns the builder for the settings used for calls to commit.
commitSettings() - Method in class com.google.cloud.spanner.v1.SpannerSettings
Returns the object with the settings used for calls to commit.
commitSettings() - Method in class com.google.cloud.spanner.v1.stub.SpannerStubSettings.Builder
Returns the builder for the settings used for calls to commit.
commitSettings() - Method in class com.google.cloud.spanner.v1.stub.SpannerStubSettings
Returns the object with the settings used for calls to commit.
configure(ApiCallContext, ReqT, MethodDescriptor<ReqT, RespT>) - Method in interface com.google.cloud.spanner.SpannerOptions.CallContextConfigurator
Configure a ApiCallContext for a specific RPC call.
configure(ApiCallContext, ReqT, MethodDescriptor<ReqT, RespT>) - Method in class com.google.cloud.spanner.SpannerOptions.SpannerCallContextTimeoutConfigurator
 
Connection - Interface in com.google.cloud.spanner.connection
Internal connection API for Google Cloud Spanner.
Connection.InternalMetadataQuery - Class in com.google.cloud.spanner.connection
This query option is used internally to indicate that a query is executed by the library itself to fetch metadata.
ConnectionOptions - Class in com.google.cloud.spanner.connection
Internal connection API for Google Cloud Spanner.
ConnectionOptions.Builder - Class in com.google.cloud.spanner.connection
Builder for ConnectionOptions instances.
ConnectionOptions.ConnectionProperty - Class in com.google.cloud.spanner.connection
Supported connection properties that can be included in the connection URI.
create() - Static method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Constructs an instance of DatabaseAdminClient with default settings.
create(DatabaseAdminSettings) - Static method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Constructs an instance of DatabaseAdminClient, using the given settings.
create(DatabaseAdminStub) - Static method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Constructs an instance of DatabaseAdminClient, using the given stub for making calls.
create(DatabaseAdminStubSettings) - Static method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminSettings
 
create(DatabaseAdminStubSettings) - Static method in class com.google.cloud.spanner.admin.database.v1.stub.GrpcDatabaseAdminStub
 
create(ClientContext) - Static method in class com.google.cloud.spanner.admin.database.v1.stub.GrpcDatabaseAdminStub
 
create(ClientContext, GrpcStubCallableFactory) - Static method in class com.google.cloud.spanner.admin.database.v1.stub.GrpcDatabaseAdminStub
 
create() - Static method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminClient
Constructs an instance of InstanceAdminClient with default settings.
create(InstanceAdminSettings) - Static method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminClient
Constructs an instance of InstanceAdminClient, using the given settings.
create(InstanceAdminStub) - Static method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminClient
Constructs an instance of InstanceAdminClient, using the given stub for making calls.
create(InstanceAdminStubSettings) - Static method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminSettings
 
create(InstanceAdminStubSettings) - Static method in class com.google.cloud.spanner.admin.instance.v1.stub.GrpcInstanceAdminStub
 
create(ClientContext) - Static method in class com.google.cloud.spanner.admin.instance.v1.stub.GrpcInstanceAdminStub
 
create(ClientContext, GrpcStubCallableFactory) - Static method in class com.google.cloud.spanner.admin.instance.v1.stub.GrpcInstanceAdminStub
 
create() - Method in class com.google.cloud.spanner.Backup
Creates a backup on the server based on the source of this Backup instance.
create() - Static method in class com.google.cloud.spanner.SpannerOptions.SpannerCallContextTimeoutConfigurator
 
create(SpannerOptions) - Static method in class com.google.cloud.spanner.spi.v1.GapicSpannerRpc
 
create(InstanceId) - Static method in class com.google.cloud.spanner.testing.RemoteSpannerHelper
Creates a RemoteSpannerHelper bound to the given instance ID.
create(SpannerOptions, InstanceId) - Static method in class com.google.cloud.spanner.testing.RemoteSpannerHelper
Creates a RemoteSpannerHelper for the given option and bound to the given instance ID.
create() - Static method in class com.google.cloud.spanner.v1.SpannerClient
Constructs an instance of SpannerClient with default settings.
create(SpannerSettings) - Static method in class com.google.cloud.spanner.v1.SpannerClient
Constructs an instance of SpannerClient, using the given settings.
create(SpannerStub) - Static method in class com.google.cloud.spanner.v1.SpannerClient
Constructs an instance of SpannerClient, using the given stub for making calls.
create(SpannerStubSettings) - Static method in class com.google.cloud.spanner.v1.SpannerSettings
 
create(SpannerStubSettings) - Static method in class com.google.cloud.spanner.v1.stub.GrpcSpannerStub
 
create(ClientContext) - Static method in class com.google.cloud.spanner.v1.stub.GrpcSpannerStub
 
create(ClientContext, GrpcStubCallableFactory) - Static method in class com.google.cloud.spanner.v1.stub.GrpcSpannerStub
 
createAsync(PageContext<ListBackupOperationsRequest, ListBackupOperationsResponse, Operation>, ApiFuture<ListBackupOperationsResponse>) - Static method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient.ListBackupOperationsPagedResponse
 
createAsync(PageContext<ListBackupsRequest, ListBackupsResponse, Backup>, ApiFuture<ListBackupsResponse>) - Static method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient.ListBackupsPagedResponse
 
createAsync(PageContext<ListDatabaseOperationsRequest, ListDatabaseOperationsResponse, Operation>, ApiFuture<ListDatabaseOperationsResponse>) - Static method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient.ListDatabaseOperationsPagedResponse
 
createAsync(PageContext<ListDatabasesRequest, ListDatabasesResponse, Database>, ApiFuture<ListDatabasesResponse>) - Static method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient.ListDatabasesPagedResponse
 
createAsync(PageContext<ListInstanceConfigsRequest, ListInstanceConfigsResponse, InstanceConfig>, ApiFuture<ListInstanceConfigsResponse>) - Static method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminClient.ListInstanceConfigsPagedResponse
 
createAsync(PageContext<ListInstancesRequest, ListInstancesResponse, Instance>, ApiFuture<ListInstancesResponse>) - Static method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminClient.ListInstancesPagedResponse
 
createAsync(PageContext<ListSessionsRequest, ListSessionsResponse, Session>, ApiFuture<ListSessionsResponse>) - Static method in class com.google.cloud.spanner.v1.SpannerClient.ListSessionsPagedResponse
 
createBackup(String, String, String, Timestamp) - Method in interface com.google.cloud.spanner.DatabaseAdminClient
Creates a new backup from a database in a Cloud Spanner instance.
createBackup(String, String, Backup) - Method in class com.google.cloud.spanner.spi.v1.GapicSpannerRpc
 
createBackup(String, String, Backup) - Method in interface com.google.cloud.spanner.spi.v1.SpannerRpc
Creates a new backup from the source database specified in the Backup instance.
createBackupAsync(InstanceName, Backup, String) - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Starts creating a new Cloud Spanner Backup.
createBackupAsync(String, Backup, String) - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Starts creating a new Cloud Spanner Backup.
createBackupAsync(CreateBackupRequest) - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Starts creating a new Cloud Spanner Backup.
createBackupCallable() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Starts creating a new Cloud Spanner Backup.
createBackupCallable() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStub
 
createBackupCallable() - Method in class com.google.cloud.spanner.admin.database.v1.stub.GrpcDatabaseAdminStub
 
createBackupOperationCallable() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Starts creating a new Cloud Spanner Backup.
createBackupOperationCallable() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStub
 
createBackupOperationCallable() - Method in class com.google.cloud.spanner.admin.database.v1.stub.GrpcDatabaseAdminStub
 
createBackupOperationSettings() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminSettings.Builder
Returns the builder for the settings used for calls to createBackup.
createBackupOperationSettings() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminSettings
Returns the object with the settings used for calls to createBackup.
createBackupOperationSettings() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStubSettings.Builder
Returns the builder for the settings used for calls to createBackup.
createBackupOperationSettings() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStubSettings
Returns the object with the settings used for calls to createBackup.
createBackupSettings() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminSettings.Builder
Returns the builder for the settings used for calls to createBackup.
createBackupSettings() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminSettings
Returns the object with the settings used for calls to createBackup.
createBackupSettings() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStubSettings.Builder
Returns the builder for the settings used for calls to createBackup.
createBackupSettings() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStubSettings
Returns the object with the settings used for calls to createBackup.
createBatchingCallable(GrpcCallSettings<RequestT, ResponseT>, BatchingCallSettings<RequestT, ResponseT>, ClientContext) - Method in class com.google.cloud.spanner.admin.database.v1.stub.GrpcDatabaseAdminCallableFactory
 
createBatchingCallable(GrpcCallSettings<RequestT, ResponseT>, BatchingCallSettings<RequestT, ResponseT>, ClientContext) - Method in class com.google.cloud.spanner.admin.instance.v1.stub.GrpcInstanceAdminCallableFactory
 
createBatchingCallable(GrpcCallSettings<RequestT, ResponseT>, BatchingCallSettings<RequestT, ResponseT>, ClientContext) - Method in class com.google.cloud.spanner.v1.stub.GrpcSpannerCallableFactory
 
createBidiStreamingCallable(GrpcCallSettings<RequestT, ResponseT>, StreamingCallSettings<RequestT, ResponseT>, ClientContext) - Method in class com.google.cloud.spanner.admin.database.v1.stub.GrpcDatabaseAdminCallableFactory
 
createBidiStreamingCallable(GrpcCallSettings<RequestT, ResponseT>, StreamingCallSettings<RequestT, ResponseT>, ClientContext) - Method in class com.google.cloud.spanner.admin.instance.v1.stub.GrpcInstanceAdminCallableFactory
 
createBidiStreamingCallable(GrpcCallSettings<RequestT, ResponseT>, StreamingCallSettings<RequestT, ResponseT>, ClientContext) - Method in class com.google.cloud.spanner.v1.stub.GrpcSpannerCallableFactory
 
createClientStreamingCallable(GrpcCallSettings<RequestT, ResponseT>, StreamingCallSettings<RequestT, ResponseT>, ClientContext) - Method in class com.google.cloud.spanner.admin.database.v1.stub.GrpcDatabaseAdminCallableFactory
 
createClientStreamingCallable(GrpcCallSettings<RequestT, ResponseT>, StreamingCallSettings<RequestT, ResponseT>, ClientContext) - Method in class com.google.cloud.spanner.admin.instance.v1.stub.GrpcInstanceAdminCallableFactory
 
createClientStreamingCallable(GrpcCallSettings<RequestT, ResponseT>, StreamingCallSettings<RequestT, ResponseT>, ClientContext) - Method in class com.google.cloud.spanner.v1.stub.GrpcSpannerCallableFactory
 
createCollection(List<DatabaseAdminClient.ListBackupOperationsPage>, int) - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient.ListBackupOperationsFixedSizeCollection
 
createCollection(List<DatabaseAdminClient.ListBackupsPage>, int) - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient.ListBackupsFixedSizeCollection
 
createCollection(List<DatabaseAdminClient.ListDatabaseOperationsPage>, int) - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient.ListDatabaseOperationsFixedSizeCollection
 
createCollection(List<DatabaseAdminClient.ListDatabasesPage>, int) - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient.ListDatabasesFixedSizeCollection
 
createCollection(List<InstanceAdminClient.ListInstanceConfigsPage>, int) - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminClient.ListInstanceConfigsFixedSizeCollection
 
createCollection(List<InstanceAdminClient.ListInstancesPage>, int) - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminClient.ListInstancesFixedSizeCollection
 
createCollection(List<SpannerClient.ListSessionsPage>, int) - Method in class com.google.cloud.spanner.v1.SpannerClient.ListSessionsFixedSizeCollection
 
createDatabase(String, String, Iterable<String>) - Method in interface com.google.cloud.spanner.DatabaseAdminClient
Creates a new database in a Cloud Spanner instance.
createDatabase(String, Iterable<String>) - Method in class com.google.cloud.spanner.Instance
Creates a new database in this instance.
createDatabase(String, String, Iterable<String>) - Method in class com.google.cloud.spanner.spi.v1.GapicSpannerRpc
 
createDatabase(String, String, Iterable<String>) - Method in interface com.google.cloud.spanner.spi.v1.SpannerRpc
 
createDatabaseAsync(InstanceName, String) - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Creates a new Cloud Spanner database and starts to prepare it for serving.
createDatabaseAsync(String, String) - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Creates a new Cloud Spanner database and starts to prepare it for serving.
createDatabaseAsync(CreateDatabaseRequest) - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Creates a new Cloud Spanner database and starts to prepare it for serving.
createDatabaseCallable() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Creates a new Cloud Spanner database and starts to prepare it for serving.
createDatabaseCallable() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStub
 
createDatabaseCallable() - Method in class com.google.cloud.spanner.admin.database.v1.stub.GrpcDatabaseAdminStub
 
createDatabaseOperationCallable() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Creates a new Cloud Spanner database and starts to prepare it for serving.
createDatabaseOperationCallable() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStub
 
createDatabaseOperationCallable() - Method in class com.google.cloud.spanner.admin.database.v1.stub.GrpcDatabaseAdminStub
 
createDatabaseOperationSettings() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminSettings.Builder
Returns the builder for the settings used for calls to createDatabase.
createDatabaseOperationSettings() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminSettings
Returns the object with the settings used for calls to createDatabase.
createDatabaseOperationSettings() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStubSettings.Builder
Returns the builder for the settings used for calls to createDatabase.
createDatabaseOperationSettings() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStubSettings
Returns the object with the settings used for calls to createDatabase.
createDatabaseSettings() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminSettings.Builder
Returns the builder for the settings used for calls to createDatabase.
createDatabaseSettings() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminSettings
Returns the object with the settings used for calls to createDatabase.
createDatabaseSettings() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStubSettings.Builder
Returns the builder for the settings used for calls to createDatabase.
createDatabaseSettings() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStubSettings
Returns the object with the settings used for calls to createDatabase.
createDefault() - Static method in class com.google.cloud.spanner.spi.v1.SpannerInterceptorProvider
 
createInstance(InstanceInfo) - Method in interface com.google.cloud.spanner.InstanceAdminClient
Creates an instance and begins preparing it to begin serving.
createInstance(String, String, Instance) - Method in class com.google.cloud.spanner.spi.v1.GapicSpannerRpc
 
createInstance(String, String, Instance) - Method in interface com.google.cloud.spanner.spi.v1.SpannerRpc
 
createInstanceAsync(ProjectName, String, Instance) - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminClient
Creates an instance and begins preparing it to begin serving.
createInstanceAsync(String, String, Instance) - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminClient
Creates an instance and begins preparing it to begin serving.
createInstanceAsync(CreateInstanceRequest) - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminClient
Creates an instance and begins preparing it to begin serving.
createInstanceCallable() - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminClient
Creates an instance and begins preparing it to begin serving.
createInstanceCallable() - Method in class com.google.cloud.spanner.admin.instance.v1.stub.GrpcInstanceAdminStub
 
createInstanceCallable() - Method in class com.google.cloud.spanner.admin.instance.v1.stub.InstanceAdminStub
 
createInstanceOperationCallable() - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminClient
Creates an instance and begins preparing it to begin serving.
createInstanceOperationCallable() - Method in class com.google.cloud.spanner.admin.instance.v1.stub.GrpcInstanceAdminStub
 
createInstanceOperationCallable() - Method in class com.google.cloud.spanner.admin.instance.v1.stub.InstanceAdminStub
 
createInstanceOperationSettings() - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminSettings.Builder
Returns the builder for the settings used for calls to createInstance.
createInstanceOperationSettings() - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminSettings
Returns the object with the settings used for calls to createInstance.
createInstanceOperationSettings() - Method in class com.google.cloud.spanner.admin.instance.v1.stub.InstanceAdminStubSettings.Builder
Returns the builder for the settings used for calls to createInstance.
createInstanceOperationSettings() - Method in class com.google.cloud.spanner.admin.instance.v1.stub.InstanceAdminStubSettings
Returns the object with the settings used for calls to createInstance.
createInstanceSettings() - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminSettings.Builder
Returns the builder for the settings used for calls to createInstance.
createInstanceSettings() - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminSettings
Returns the object with the settings used for calls to createInstance.
createInstanceSettings() - Method in class com.google.cloud.spanner.admin.instance.v1.stub.InstanceAdminStubSettings.Builder
Returns the builder for the settings used for calls to createInstance.
createInstanceSettings() - Method in class com.google.cloud.spanner.admin.instance.v1.stub.InstanceAdminStubSettings
Returns the object with the settings used for calls to createInstance.
createOperationCallable(GrpcCallSettings<RequestT, Operation>, OperationCallSettings<RequestT, ResponseT, MetadataT>, ClientContext, OperationsStub) - Method in class com.google.cloud.spanner.admin.database.v1.stub.GrpcDatabaseAdminCallableFactory
 
createOperationCallable(GrpcCallSettings<RequestT, Operation>, OperationCallSettings<RequestT, ResponseT, MetadataT>, ClientContext, OperationsStub) - Method in class com.google.cloud.spanner.admin.instance.v1.stub.GrpcInstanceAdminCallableFactory
 
createOperationCallable(GrpcCallSettings<RequestT, Operation>, OperationCallSettings<RequestT, ResponseT, MetadataT>, ClientContext, OperationsStub) - Method in class com.google.cloud.spanner.v1.stub.GrpcSpannerCallableFactory
 
createPage(PageContext<ListBackupOperationsRequest, ListBackupOperationsResponse, Operation>, ListBackupOperationsResponse) - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient.ListBackupOperationsPage
 
createPage(PageContext<ListBackupsRequest, ListBackupsResponse, Backup>, ListBackupsResponse) - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient.ListBackupsPage
 
createPage(PageContext<ListDatabaseOperationsRequest, ListDatabaseOperationsResponse, Operation>, ListDatabaseOperationsResponse) - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient.ListDatabaseOperationsPage
 
createPage(PageContext<ListDatabasesRequest, ListDatabasesResponse, Database>, ListDatabasesResponse) - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient.ListDatabasesPage
 
createPage(PageContext<ListInstanceConfigsRequest, ListInstanceConfigsResponse, InstanceConfig>, ListInstanceConfigsResponse) - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminClient.ListInstanceConfigsPage
 
createPage(PageContext<ListInstancesRequest, ListInstancesResponse, Instance>, ListInstancesResponse) - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminClient.ListInstancesPage
 
createPage(PageContext<ListSessionsRequest, ListSessionsResponse, Session>, ListSessionsResponse) - Method in class com.google.cloud.spanner.v1.SpannerClient.ListSessionsPage
 
createPageAsync(PageContext<ListBackupOperationsRequest, ListBackupOperationsResponse, Operation>, ApiFuture<ListBackupOperationsResponse>) - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient.ListBackupOperationsPage
 
createPageAsync(PageContext<ListBackupsRequest, ListBackupsResponse, Backup>, ApiFuture<ListBackupsResponse>) - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient.ListBackupsPage
 
createPageAsync(PageContext<ListDatabaseOperationsRequest, ListDatabaseOperationsResponse, Operation>, ApiFuture<ListDatabaseOperationsResponse>) - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient.ListDatabaseOperationsPage
 
createPageAsync(PageContext<ListDatabasesRequest, ListDatabasesResponse, Database>, ApiFuture<ListDatabasesResponse>) - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient.ListDatabasesPage
 
createPageAsync(PageContext<ListInstanceConfigsRequest, ListInstanceConfigsResponse, InstanceConfig>, ApiFuture<ListInstanceConfigsResponse>) - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminClient.ListInstanceConfigsPage
 
createPageAsync(PageContext<ListInstancesRequest, ListInstancesResponse, Instance>, ApiFuture<ListInstancesResponse>) - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminClient.ListInstancesPage
 
createPageAsync(PageContext<ListSessionsRequest, ListSessionsResponse, Session>, ApiFuture<ListSessionsResponse>) - Method in class com.google.cloud.spanner.v1.SpannerClient.ListSessionsPage
 
createPagedCallable(GrpcCallSettings<RequestT, ResponseT>, PagedCallSettings<RequestT, ResponseT, PagedListResponseT>, ClientContext) - Method in class com.google.cloud.spanner.admin.database.v1.stub.GrpcDatabaseAdminCallableFactory
 
createPagedCallable(GrpcCallSettings<RequestT, ResponseT>, PagedCallSettings<RequestT, ResponseT, PagedListResponseT>, ClientContext) - Method in class com.google.cloud.spanner.admin.instance.v1.stub.GrpcInstanceAdminCallableFactory
 
createPagedCallable(GrpcCallSettings<RequestT, ResponseT>, PagedCallSettings<RequestT, ResponseT, PagedListResponseT>, ClientContext) - Method in class com.google.cloud.spanner.v1.stub.GrpcSpannerCallableFactory
 
createServerStreamingCallable(GrpcCallSettings<RequestT, ResponseT>, ServerStreamingCallSettings<RequestT, ResponseT>, ClientContext) - Method in class com.google.cloud.spanner.admin.database.v1.stub.GrpcDatabaseAdminCallableFactory
 
createServerStreamingCallable(GrpcCallSettings<RequestT, ResponseT>, ServerStreamingCallSettings<RequestT, ResponseT>, ClientContext) - Method in class com.google.cloud.spanner.admin.instance.v1.stub.GrpcInstanceAdminCallableFactory
 
createServerStreamingCallable(GrpcCallSettings<RequestT, ResponseT>, ServerStreamingCallSettings<RequestT, ResponseT>, ClientContext) - Method in class com.google.cloud.spanner.v1.stub.GrpcSpannerCallableFactory
 
createSession(String, Map<String, String>, Map<SpannerRpc.Option, ?>) - Method in class com.google.cloud.spanner.spi.v1.GapicSpannerRpc
 
createSession(String, Map<String, String>, Map<SpannerRpc.Option, ?>) - Method in interface com.google.cloud.spanner.spi.v1.SpannerRpc
 
createSession(DatabaseName) - Method in class com.google.cloud.spanner.v1.SpannerClient
Creates a new session.
createSession(String) - Method in class com.google.cloud.spanner.v1.SpannerClient
Creates a new session.
createSession(CreateSessionRequest) - Method in class com.google.cloud.spanner.v1.SpannerClient
Creates a new session.
createSessionCallable() - Method in class com.google.cloud.spanner.v1.SpannerClient
Creates a new session.
createSessionCallable() - Method in class com.google.cloud.spanner.v1.stub.GrpcSpannerStub
 
createSessionCallable() - Method in class com.google.cloud.spanner.v1.stub.SpannerStub
 
createSessionSettings() - Method in class com.google.cloud.spanner.v1.SpannerSettings.Builder
Returns the builder for the settings used for calls to createSession.
createSessionSettings() - Method in class com.google.cloud.spanner.v1.SpannerSettings
Returns the object with the settings used for calls to createSession.
createSessionSettings() - Method in class com.google.cloud.spanner.v1.stub.SpannerStubSettings.Builder
Returns the builder for the settings used for calls to createSession.
createSessionSettings() - Method in class com.google.cloud.spanner.v1.stub.SpannerStubSettings
Returns the object with the settings used for calls to createSession.
createStub() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStubSettings
 
createStub() - Method in class com.google.cloud.spanner.admin.instance.v1.stub.InstanceAdminStubSettings
 
createStub() - Method in class com.google.cloud.spanner.v1.stub.SpannerStubSettings
 
createTestDatabase(String...) - Method in class com.google.cloud.spanner.testing.RemoteSpannerHelper
Creates a test database defined by statements.
createTestDatabase(Iterable<String>) - Method in class com.google.cloud.spanner.testing.RemoteSpannerHelper
Creates a test database defined by statements in the test instance.
createUnaryCallable(GrpcCallSettings<RequestT, ResponseT>, UnaryCallSettings<RequestT, ResponseT>, ClientContext) - Method in class com.google.cloud.spanner.admin.database.v1.stub.GrpcDatabaseAdminCallableFactory
 
createUnaryCallable(GrpcCallSettings<RequestT, ResponseT>, UnaryCallSettings<RequestT, ResponseT>, ClientContext) - Method in class com.google.cloud.spanner.admin.instance.v1.stub.GrpcInstanceAdminCallableFactory
 
createUnaryCallable(GrpcCallSettings<RequestT, ResponseT>, UnaryCallSettings<RequestT, ResponseT>, ClientContext) - Method in class com.google.cloud.spanner.v1.stub.GrpcSpannerCallableFactory
 
CREDENTIALS_PROPERTY_NAME - Static variable in class com.google.cloud.spanner.connection.ConnectionOptions
Name of the 'credentials' connection property.
cursorReady(AsyncResultSet) - Method in interface com.google.cloud.spanner.AsyncResultSet.ReadyCallback
 

D

Database - Class in com.google.cloud.spanner
Represents a Cloud Spanner database.
Database(DatabaseId, DatabaseInfo.State, DatabaseAdminClient) - Constructor for class com.google.cloud.spanner.Database
 
Database.Builder - Class in com.google.cloud.spanner
 
DatabaseAdminClient - Class in com.google.cloud.spanner.admin.database.v1
Service Description: Cloud Spanner Database Admin API
DatabaseAdminClient(DatabaseAdminSettings) - Constructor for class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Constructs an instance of DatabaseAdminClient, using the given settings.
DatabaseAdminClient(DatabaseAdminStub) - Constructor for class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
 
DatabaseAdminClient - Interface in com.google.cloud.spanner
Client to do admin operations on a Cloud Spanner Database.
DatabaseAdminClient.ListBackupOperationsFixedSizeCollection - Class in com.google.cloud.spanner.admin.database.v1
 
DatabaseAdminClient.ListBackupOperationsPage - Class in com.google.cloud.spanner.admin.database.v1
 
DatabaseAdminClient.ListBackupOperationsPagedResponse - Class in com.google.cloud.spanner.admin.database.v1
 
DatabaseAdminClient.ListBackupsFixedSizeCollection - Class in com.google.cloud.spanner.admin.database.v1
 
DatabaseAdminClient.ListBackupsPage - Class in com.google.cloud.spanner.admin.database.v1
 
DatabaseAdminClient.ListBackupsPagedResponse - Class in com.google.cloud.spanner.admin.database.v1
 
DatabaseAdminClient.ListDatabaseOperationsFixedSizeCollection - Class in com.google.cloud.spanner.admin.database.v1
 
DatabaseAdminClient.ListDatabaseOperationsPage - Class in com.google.cloud.spanner.admin.database.v1
 
DatabaseAdminClient.ListDatabaseOperationsPagedResponse - Class in com.google.cloud.spanner.admin.database.v1
 
DatabaseAdminClient.ListDatabasesFixedSizeCollection - Class in com.google.cloud.spanner.admin.database.v1
 
DatabaseAdminClient.ListDatabasesPage - Class in com.google.cloud.spanner.admin.database.v1
 
DatabaseAdminClient.ListDatabasesPagedResponse - Class in com.google.cloud.spanner.admin.database.v1
 
DatabaseAdminSettings - Class in com.google.cloud.spanner.admin.database.v1
Settings class to configure an instance of DatabaseAdminClient.
DatabaseAdminSettings(DatabaseAdminSettings.Builder) - Constructor for class com.google.cloud.spanner.admin.database.v1.DatabaseAdminSettings
 
DatabaseAdminSettings.Builder - Class in com.google.cloud.spanner.admin.database.v1
Builder for DatabaseAdminSettings.
DatabaseAdminStub - Class in com.google.cloud.spanner.admin.database.v1.stub
Base stub class for the DatabaseAdmin service API.
DatabaseAdminStub() - Constructor for class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStub
 
DatabaseAdminStubSettings - Class in com.google.cloud.spanner.admin.database.v1.stub
Settings class to configure an instance of DatabaseAdminStub.
DatabaseAdminStubSettings(DatabaseAdminStubSettings.Builder) - Constructor for class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStubSettings
 
DatabaseAdminStubSettings.Builder - Class in com.google.cloud.spanner.admin.database.v1.stub
Builder for DatabaseAdminStubSettings.
DatabaseClient - Interface in com.google.cloud.spanner
Interface for all the APIs that are used to read/write data into a Cloud Spanner database.
DatabaseId - Class in com.google.cloud.spanner
Represents an id of a Cloud Spanner database resource.
DatabaseInfo - Class in com.google.cloud.spanner
Represents a Cloud Spanner database.
DatabaseInfo(DatabaseId, DatabaseInfo.State) - Constructor for class com.google.cloud.spanner.DatabaseInfo
 
DatabaseInfo.Builder - Class in com.google.cloud.spanner
 
DatabaseInfo.State - Enum in com.google.cloud.spanner
State of the database.
DatabaseNotFoundException - Exception in com.google.cloud.spanner
Exception thrown by Cloud Spanner when an operation detects that the database that is being used no longer exists.
date() - Static method in class com.google.cloud.spanner.Type
Returns the descriptor for the DATE type: a timezone independent date in the range [1678-01-01, 2262-01-01).
date(Date) - Static method in class com.google.cloud.spanner.Value
Returns a DATE value.
dateArray(Iterable<Date>) - Static method in class com.google.cloud.spanner.Value
Returns an ARRAY<DATE> value.
defaultApiClientHeaderProviderBuilder() - Static method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminSettings
 
defaultApiClientHeaderProviderBuilder() - Static method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStubSettings
 
defaultApiClientHeaderProviderBuilder() - Static method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminSettings
 
defaultApiClientHeaderProviderBuilder() - Static method in class com.google.cloud.spanner.admin.instance.v1.stub.InstanceAdminStubSettings
 
defaultApiClientHeaderProviderBuilder() - Static method in class com.google.cloud.spanner.v1.SpannerSettings
 
defaultApiClientHeaderProviderBuilder() - Static method in class com.google.cloud.spanner.v1.stub.SpannerStubSettings
 
defaultCredentialsProviderBuilder() - Static method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminSettings
Returns a builder for the default credentials for this service.
defaultCredentialsProviderBuilder() - Static method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStubSettings
Returns a builder for the default credentials for this service.
defaultCredentialsProviderBuilder() - Static method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminSettings
Returns a builder for the default credentials for this service.
defaultCredentialsProviderBuilder() - Static method in class com.google.cloud.spanner.admin.instance.v1.stub.InstanceAdminStubSettings
Returns a builder for the default credentials for this service.
defaultCredentialsProviderBuilder() - Static method in class com.google.cloud.spanner.v1.SpannerSettings
Returns a builder for the default credentials for this service.
defaultCredentialsProviderBuilder() - Static method in class com.google.cloud.spanner.v1.stub.SpannerStubSettings
Returns a builder for the default credentials for this service.
defaultExecutorProviderBuilder() - Static method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminSettings
Returns a builder for the default ExecutorProvider for this service.
defaultExecutorProviderBuilder() - Static method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStubSettings
Returns a builder for the default ExecutorProvider for this service.
defaultExecutorProviderBuilder() - Static method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminSettings
Returns a builder for the default ExecutorProvider for this service.
defaultExecutorProviderBuilder() - Static method in class com.google.cloud.spanner.admin.instance.v1.stub.InstanceAdminStubSettings
Returns a builder for the default ExecutorProvider for this service.
defaultExecutorProviderBuilder() - Static method in class com.google.cloud.spanner.v1.SpannerSettings
Returns a builder for the default ExecutorProvider for this service.
defaultExecutorProviderBuilder() - Static method in class com.google.cloud.spanner.v1.stub.SpannerStubSettings
Returns a builder for the default ExecutorProvider for this service.
defaultGrpcTransportProviderBuilder() - Static method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminSettings
Returns a builder for the default ChannelProvider for this service.
defaultGrpcTransportProviderBuilder() - Static method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStubSettings
Returns a builder for the default ChannelProvider for this service.
defaultGrpcTransportProviderBuilder() - Static method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminSettings
Returns a builder for the default ChannelProvider for this service.
defaultGrpcTransportProviderBuilder() - Static method in class com.google.cloud.spanner.admin.instance.v1.stub.InstanceAdminStubSettings
Returns a builder for the default ChannelProvider for this service.
defaultGrpcTransportProviderBuilder() - Static method in class com.google.cloud.spanner.v1.SpannerSettings
Returns a builder for the default ChannelProvider for this service.
defaultGrpcTransportProviderBuilder() - Static method in class com.google.cloud.spanner.v1.stub.SpannerStubSettings
Returns a builder for the default ChannelProvider for this service.
defaultTransportChannelProvider() - Static method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminSettings
 
defaultTransportChannelProvider() - Static method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStubSettings
 
defaultTransportChannelProvider() - Static method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminSettings
 
defaultTransportChannelProvider() - Static method in class com.google.cloud.spanner.admin.instance.v1.stub.InstanceAdminStubSettings
 
defaultTransportChannelProvider() - Static method in class com.google.cloud.spanner.v1.SpannerSettings
 
defaultTransportChannelProvider() - Static method in class com.google.cloud.spanner.v1.stub.SpannerStubSettings
 
delete() - Method in class com.google.cloud.spanner.Backup
Deletes this backup on Cloud Spanner.
delete() - Method in class com.google.cloud.spanner.Instance
 
delete(String, Key) - Static method in class com.google.cloud.spanner.Mutation
Returns a mutation that will delete the row with primary key key.
delete(String, KeySet) - Static method in class com.google.cloud.spanner.Mutation
Returns a mutation that will delete all rows with primary keys covered by keySet.
deleteBackup(BackupName) - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Deletes a pending or completed [Backup][google.spanner.admin.database.v1.Backup].
deleteBackup(String) - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Deletes a pending or completed [Backup][google.spanner.admin.database.v1.Backup].
deleteBackup(DeleteBackupRequest) - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Deletes a pending or completed [Backup][google.spanner.admin.database.v1.Backup].
deleteBackup(String, String) - Method in interface com.google.cloud.spanner.DatabaseAdminClient
Deletes a pending or completed backup.
deleteBackup(String) - Method in class com.google.cloud.spanner.spi.v1.GapicSpannerRpc
 
deleteBackup(String) - Method in interface com.google.cloud.spanner.spi.v1.SpannerRpc
Deletes a pending or completed backup.
deleteBackupCallable() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Deletes a pending or completed [Backup][google.spanner.admin.database.v1.Backup].
deleteBackupCallable() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStub
 
deleteBackupCallable() - Method in class com.google.cloud.spanner.admin.database.v1.stub.GrpcDatabaseAdminStub
 
deleteBackupSettings() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminSettings.Builder
Returns the builder for the settings used for calls to deleteBackup.
deleteBackupSettings() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminSettings
Returns the object with the settings used for calls to deleteBackup.
deleteBackupSettings() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStubSettings.Builder
Returns the builder for the settings used for calls to deleteBackup.
deleteBackupSettings() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStubSettings
Returns the object with the settings used for calls to deleteBackup.
deleteInstance(InstanceName) - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminClient
Deletes an instance.
deleteInstance(String) - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminClient
Deletes an instance.
deleteInstance(DeleteInstanceRequest) - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminClient
Deletes an instance.
deleteInstance(String) - Method in interface com.google.cloud.spanner.InstanceAdminClient
Deletes an instance.
deleteInstance(String) - Method in class com.google.cloud.spanner.spi.v1.GapicSpannerRpc
 
deleteInstance(String) - Method in interface com.google.cloud.spanner.spi.v1.SpannerRpc
 
deleteInstanceCallable() - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminClient
Deletes an instance.
deleteInstanceCallable() - Method in class com.google.cloud.spanner.admin.instance.v1.stub.GrpcInstanceAdminStub
 
deleteInstanceCallable() - Method in class com.google.cloud.spanner.admin.instance.v1.stub.InstanceAdminStub
 
deleteInstanceSettings() - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminSettings.Builder
Returns the builder for the settings used for calls to deleteInstance.
deleteInstanceSettings() - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminSettings
Returns the object with the settings used for calls to deleteInstance.
deleteInstanceSettings() - Method in class com.google.cloud.spanner.admin.instance.v1.stub.InstanceAdminStubSettings.Builder
Returns the builder for the settings used for calls to deleteInstance.
deleteInstanceSettings() - Method in class com.google.cloud.spanner.admin.instance.v1.stub.InstanceAdminStubSettings
Returns the object with the settings used for calls to deleteInstance.
deleteSession(String, Map<SpannerRpc.Option, ?>) - Method in class com.google.cloud.spanner.spi.v1.GapicSpannerRpc
 
deleteSession(String, Map<SpannerRpc.Option, ?>) - Method in interface com.google.cloud.spanner.spi.v1.SpannerRpc
 
deleteSession(SessionName) - Method in class com.google.cloud.spanner.v1.SpannerClient
Ends a session, releasing server resources associated with it.
deleteSession(String) - Method in class com.google.cloud.spanner.v1.SpannerClient
Ends a session, releasing server resources associated with it.
deleteSession(DeleteSessionRequest) - Method in class com.google.cloud.spanner.v1.SpannerClient
Ends a session, releasing server resources associated with it.
deleteSessionCallable() - Method in class com.google.cloud.spanner.v1.SpannerClient
Ends a session, releasing server resources associated with it.
deleteSessionCallable() - Method in class com.google.cloud.spanner.v1.stub.GrpcSpannerStub
 
deleteSessionCallable() - Method in class com.google.cloud.spanner.v1.stub.SpannerStub
 
deleteSessionSettings() - Method in class com.google.cloud.spanner.v1.SpannerSettings.Builder
Returns the builder for the settings used for calls to deleteSession.
deleteSessionSettings() - Method in class com.google.cloud.spanner.v1.SpannerSettings
Returns the object with the settings used for calls to deleteSession.
deleteSessionSettings() - Method in class com.google.cloud.spanner.v1.stub.SpannerStubSettings.Builder
Returns the builder for the settings used for calls to deleteSession.
deleteSessionSettings() - Method in class com.google.cloud.spanner.v1.stub.SpannerStubSettings
Returns the object with the settings used for calls to deleteSession.
doWorkAsync(TransactionContext) - Method in interface com.google.cloud.spanner.AsyncRunner.AsyncWork
Performs a single transaction attempt.
drop() - Method in class com.google.cloud.spanner.Database
Drops this database.
dropDatabase(DatabaseName) - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Drops (aka deletes) a Cloud Spanner database.
dropDatabase(String) - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Drops (aka deletes) a Cloud Spanner database.
dropDatabase(DropDatabaseRequest) - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Drops (aka deletes) a Cloud Spanner database.
dropDatabase(String, String) - Method in interface com.google.cloud.spanner.DatabaseAdminClient
Drops a Cloud Spanner database.
dropDatabase(String) - Method in class com.google.cloud.spanner.spi.v1.GapicSpannerRpc
 
dropDatabase(String) - Method in interface com.google.cloud.spanner.spi.v1.SpannerRpc
 
dropDatabaseCallable() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Drops (aka deletes) a Cloud Spanner database.
dropDatabaseCallable() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStub
 
dropDatabaseCallable() - Method in class com.google.cloud.spanner.admin.database.v1.stub.GrpcDatabaseAdminStub
 
dropDatabaseSettings() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminSettings.Builder
Returns the builder for the settings used for calls to dropDatabase.
dropDatabaseSettings() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminSettings
Returns the object with the settings used for calls to dropDatabase.
dropDatabaseSettings() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStubSettings.Builder
Returns the builder for the settings used for calls to dropDatabase.
dropDatabaseSettings() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStubSettings
Returns the object with the settings used for calls to dropDatabase.

E

EmulatorSpannerHelper - Class in com.google.cloud.spanner.testing
Utility class for checking emulator state for tests
EmulatorSpannerHelper() - Constructor for class com.google.cloud.spanner.testing.EmulatorSpannerHelper
 
equals(Object) - Method in class com.google.cloud.spanner.BackupId
 
equals(Object) - Method in class com.google.cloud.spanner.BackupInfo
 
equals(Object) - Method in class com.google.cloud.spanner.BatchTransactionId
 
equals(Object) - Method in class com.google.cloud.spanner.CommitResponse
 
equals(Object) - Method in class com.google.cloud.spanner.connection.ConnectionOptions.ConnectionProperty
 
equals(Object) - Method in class com.google.cloud.spanner.DatabaseId
 
equals(Object) - Method in class com.google.cloud.spanner.DatabaseInfo
 
equals(Object) - Method in class com.google.cloud.spanner.InstanceConfigId
 
equals(Object) - Method in class com.google.cloud.spanner.InstanceConfigInfo
 
equals(Object) - Method in class com.google.cloud.spanner.InstanceId
 
equals(Object) - Method in class com.google.cloud.spanner.InstanceInfo
 
equals(Object) - Method in class com.google.cloud.spanner.Key
 
equals(Object) - Method in class com.google.cloud.spanner.KeyRange
 
equals(Object) - Method in class com.google.cloud.spanner.KeySet
 
equals(Object) - Method in class com.google.cloud.spanner.Mutation
 
equals(Object) - Method in class com.google.cloud.spanner.Options
 
equals(Object) - Method in class com.google.cloud.spanner.Partition
 
equals(Object) - Method in class com.google.cloud.spanner.PartitionOptions
 
equals(Object) - Method in class com.google.cloud.spanner.Statement
 
equals(Object) - Method in class com.google.cloud.spanner.Struct
 
equals(Object) - Method in class com.google.cloud.spanner.TimestampBound
 
equals(Object) - Method in class com.google.cloud.spanner.Type
 
equals(Object) - Method in class com.google.cloud.spanner.Type.StructField
 
ErrorCode - Enum in com.google.cloud.spanner
Enumerates the major types of error that the Cloud Spanner service can produce.
execute(Partition) - Method in interface com.google.cloud.spanner.BatchReadOnlyTransaction
Execute the partition to return ResultSet.
execute(Statement) - Method in interface com.google.cloud.spanner.connection.Connection
Executes the given statement if allowed in the current TransactionMode and connection state.
executeAsync(Statement) - Method in interface com.google.cloud.spanner.connection.Connection
Executes the given statement if allowed in the current TransactionMode and connection state asynchronously.
executeBatchDml(ExecuteBatchDmlRequest, Map<SpannerRpc.Option, ?>) - Method in class com.google.cloud.spanner.spi.v1.GapicSpannerRpc
 
executeBatchDml(ExecuteBatchDmlRequest, Map<SpannerRpc.Option, ?>) - Method in interface com.google.cloud.spanner.spi.v1.SpannerRpc
 
executeBatchDml(ExecuteBatchDmlRequest) - Method in class com.google.cloud.spanner.v1.SpannerClient
Executes a batch of SQL DML statements.
executeBatchDmlAsync(ExecuteBatchDmlRequest, Map<SpannerRpc.Option, ?>) - Method in class com.google.cloud.spanner.spi.v1.GapicSpannerRpc
 
executeBatchDmlAsync(ExecuteBatchDmlRequest, Map<SpannerRpc.Option, ?>) - Method in interface com.google.cloud.spanner.spi.v1.SpannerRpc
 
executeBatchDmlCallable() - Method in class com.google.cloud.spanner.v1.SpannerClient
Executes a batch of SQL DML statements.
executeBatchDmlCallable() - Method in class com.google.cloud.spanner.v1.stub.GrpcSpannerStub
 
executeBatchDmlCallable() - Method in class com.google.cloud.spanner.v1.stub.SpannerStub
 
executeBatchDmlSettings() - Method in class com.google.cloud.spanner.v1.SpannerSettings.Builder
Returns the builder for the settings used for calls to executeBatchDml.
executeBatchDmlSettings() - Method in class com.google.cloud.spanner.v1.SpannerSettings
Returns the object with the settings used for calls to executeBatchDml.
executeBatchDmlSettings() - Method in class com.google.cloud.spanner.v1.stub.SpannerStubSettings.Builder
Returns the builder for the settings used for calls to executeBatchDml.
executeBatchDmlSettings() - Method in class com.google.cloud.spanner.v1.stub.SpannerStubSettings
Returns the object with the settings used for calls to executeBatchDml.
executeBatchUpdate(Iterable<Statement>) - Method in interface com.google.cloud.spanner.connection.Connection
Executes a list of DML statements in a single request.
executeBatchUpdateAsync(Iterable<Statement>) - Method in interface com.google.cloud.spanner.connection.Connection
Executes a list of DML statements in a single request.
executePartitionedDml(ExecuteSqlRequest, Map<SpannerRpc.Option, ?>) - Method in class com.google.cloud.spanner.spi.v1.GapicSpannerRpc
 
executePartitionedDml(ExecuteSqlRequest, Map<SpannerRpc.Option, ?>) - Method in interface com.google.cloud.spanner.spi.v1.SpannerRpc
 
executePartitionedUpdate(Statement, Options.UpdateOption...) - Method in interface com.google.cloud.spanner.DatabaseClient
Returns the lower bound of rows modified by this DML statement.
executeQuery(Statement, Options.QueryOption...) - Method in interface com.google.cloud.spanner.connection.Connection
Executes the given statement as a query and returns the result as a ResultSet.
executeQuery(Statement, Options.QueryOption...) - Method in interface com.google.cloud.spanner.ReadContext
Executes a query against the database.
executeQuery(ExecuteSqlRequest, Map<SpannerRpc.Option, ?>) - Method in class com.google.cloud.spanner.spi.v1.GapicSpannerRpc
 
executeQuery(ExecuteSqlRequest, SpannerRpc.ResultStreamConsumer, Map<SpannerRpc.Option, ?>) - Method in class com.google.cloud.spanner.spi.v1.GapicSpannerRpc
 
executeQuery(ExecuteSqlRequest, Map<SpannerRpc.Option, ?>) - Method in interface com.google.cloud.spanner.spi.v1.SpannerRpc
 
executeQuery(ExecuteSqlRequest, SpannerRpc.ResultStreamConsumer, Map<SpannerRpc.Option, ?>) - Method in interface com.google.cloud.spanner.spi.v1.SpannerRpc
 
executeQuery(ReadContext, Options.QueryOption...) - Method in class com.google.cloud.spanner.Statement
Executes the query in context.
executeQueryAsync(Statement, Options.QueryOption...) - Method in interface com.google.cloud.spanner.connection.Connection
Executes the given statement asynchronously as a query and returns the result as an AsyncResultSet.
executeQueryAsync(Statement, Options.QueryOption...) - Method in interface com.google.cloud.spanner.ReadContext
Same as #executeQuery(Statement, QueryOption...), but is guaranteed to be non-blocking and returns its results as an AsyncResultSet.
executeQueryAsync(ExecuteSqlRequest, Map<SpannerRpc.Option, ?>) - Method in class com.google.cloud.spanner.spi.v1.GapicSpannerRpc
 
executeQueryAsync(ExecuteSqlRequest, Map<SpannerRpc.Option, ?>) - Method in interface com.google.cloud.spanner.spi.v1.SpannerRpc
 
executeSql(ExecuteSqlRequest) - Method in class com.google.cloud.spanner.v1.SpannerClient
Executes an SQL statement, returning all results in a single reply.
executeSqlCallable() - Method in class com.google.cloud.spanner.v1.SpannerClient
Executes an SQL statement, returning all results in a single reply.
executeSqlCallable() - Method in class com.google.cloud.spanner.v1.stub.GrpcSpannerStub
 
executeSqlCallable() - Method in class com.google.cloud.spanner.v1.stub.SpannerStub
 
executeSqlSettings() - Method in class com.google.cloud.spanner.v1.SpannerSettings.Builder
Returns the builder for the settings used for calls to executeSql.
executeSqlSettings() - Method in class com.google.cloud.spanner.v1.SpannerSettings
Returns the object with the settings used for calls to executeSql.
executeSqlSettings() - Method in class com.google.cloud.spanner.v1.stub.SpannerStubSettings.Builder
Returns the builder for the settings used for calls to executeSql.
executeSqlSettings() - Method in class com.google.cloud.spanner.v1.stub.SpannerStubSettings
Returns the object with the settings used for calls to executeSql.
executeStreamingPartitionedDml(ExecuteSqlRequest, Map<SpannerRpc.Option, ?>, Duration) - Method in class com.google.cloud.spanner.spi.v1.GapicSpannerRpc
 
executeStreamingPartitionedDml(ExecuteSqlRequest, Map<SpannerRpc.Option, ?>, Duration) - Method in interface com.google.cloud.spanner.spi.v1.SpannerRpc
 
executeStreamingSqlCallable() - Method in class com.google.cloud.spanner.v1.SpannerClient
Like [ExecuteSql][google.spanner.v1.Spanner.ExecuteSql], except returns the result set as a stream.
executeStreamingSqlCallable() - Method in class com.google.cloud.spanner.v1.stub.GrpcSpannerStub
 
executeStreamingSqlCallable() - Method in class com.google.cloud.spanner.v1.stub.SpannerStub
 
executeStreamingSqlSettings() - Method in class com.google.cloud.spanner.v1.SpannerSettings.Builder
Returns the builder for the settings used for calls to executeStreamingSql.
executeStreamingSqlSettings() - Method in class com.google.cloud.spanner.v1.SpannerSettings
Returns the object with the settings used for calls to executeStreamingSql.
executeStreamingSqlSettings() - Method in class com.google.cloud.spanner.v1.stub.SpannerStubSettings.Builder
Returns the builder for the settings used for calls to executeStreamingSql.
executeStreamingSqlSettings() - Method in class com.google.cloud.spanner.v1.stub.SpannerStubSettings
Returns the object with the settings used for calls to executeStreamingSql.
executeUpdate(Statement) - Method in interface com.google.cloud.spanner.connection.Connection
Executes the given statement as a DML statement.
executeUpdate(Statement, Options.UpdateOption...) - Method in interface com.google.cloud.spanner.TransactionContext
Executes the DML statement(s) and returns the number of rows modified.
executeUpdateAsync(Statement) - Method in interface com.google.cloud.spanner.connection.Connection
Executes the given statement asynchronously as a DML statement.
executeUpdateAsync(Statement, Options.UpdateOption...) - Method in interface com.google.cloud.spanner.TransactionContext
Same as #executeUpdate(Statement), but is guaranteed to be non-blocking.
exists() - Method in class com.google.cloud.spanner.Backup
Returns true if a backup with the id of this Backup exists on Cloud Spanner.
exists() - Method in class com.google.cloud.spanner.Database
Returns true if a database with the id of this Database exists on Cloud Spanner.

F

filter(String) - Static method in class com.google.cloud.spanner.Options
Specifying this will cause the given filter to be applied to the list operation.
float64() - Static method in class com.google.cloud.spanner.Type
Returns the descriptor for the FLOAT64 type: a floating point type with the same value domain as a Java {code double}.
float64(Double) - Static method in class com.google.cloud.spanner.Value
Returns a FLOAT64 value.
float64(double) - Static method in class com.google.cloud.spanner.Value
Returns a FLOAT64 value.
float64Array(double[]) - Static method in class com.google.cloud.spanner.Value
Returns an ARRAY<FLOAT64> value.
float64Array(double[], int, int) - Static method in class com.google.cloud.spanner.Value
Returns an ARRAY<FLOAT64> value that takes its elements from a region of an array.
float64Array(Iterable<Double>) - Static method in class com.google.cloud.spanner.Value
Returns an ARRAY<FLOAT64> value.
forRows(Type, Iterable<Struct>) - Static method in class com.google.cloud.spanner.ResultSets
Creates a pre-populated ResultSet
ForwardingAsyncResultSet - Class in com.google.cloud.spanner
Forwarding implementation of AsyncResultSet that forwards all calls to a delegate.
ForwardingAsyncResultSet(AsyncResultSet) - Constructor for class com.google.cloud.spanner.ForwardingAsyncResultSet
 
ForwardingResultSet - Class in com.google.cloud.spanner
Forwarding implementation of ResultSet that forwards all calls to a delegate.
ForwardingResultSet(ResultSet) - Constructor for class com.google.cloud.spanner.ForwardingResultSet
 
ForwardingResultSet(Supplier<ResultSet>) - Constructor for class com.google.cloud.spanner.ForwardingResultSet
 
ForwardingStructReader - Class in com.google.cloud.spanner
Forwarding implements of StructReader
ForwardingStructReader(StructReader) - Constructor for class com.google.cloud.spanner.ForwardingStructReader
 
ForwardingStructReader(Supplier<? extends StructReader>) - Constructor for class com.google.cloud.spanner.ForwardingStructReader
 
fromGrpcStatus(Status) - Static method in enum com.google.cloud.spanner.ErrorCode
Returns the error code corresponding to a gRPC status, or UNKNOWN if not recognized.

G

GapicSpannerRpc - Class in com.google.cloud.spanner.spi.v1
Implementation of Cloud Spanner remote calls using Gapic libraries.
GapicSpannerRpc(SpannerOptions) - Constructor for class com.google.cloud.spanner.spi.v1.GapicSpannerRpc
 
geEndType() - Method in class com.google.cloud.spanner.KeyRange
Indicates whether the end key is inclusive (CLOSED) or exclusive (OPEN).
get() - Method in class com.google.cloud.spanner.AbstractLazyInitializer
Returns an initialized instance of T.
get() - Method in interface com.google.cloud.spanner.AsyncTransactionManager.CommitTimestampFuture
Returns the commit timestamp of the transaction.
get(long, TimeUnit) - Method in interface com.google.cloud.spanner.AsyncTransactionManager.CommitTimestampFuture
Same as AsyncTransactionManager.CommitTimestampFuture.get(), but will throw a TimeoutException if the transaction does not finish within the timeout.
get(ApiFuture<T>) - Static method in class com.google.cloud.spanner.SpannerApiFutures
 
getAllowedClientLibTokens() - Method in class com.google.cloud.spanner.SpannerOptions.Builder
 
getArrayElementType() - Method in class com.google.cloud.spanner.Type
Returns the type descriptor for elements of this ARRAY type.
getAsyncExecutorProvider() - Method in interface com.google.cloud.spanner.Spanner
 
getAutocommitDmlMode() - Method in interface com.google.cloud.spanner.connection.Connection
 
getBackup(BackupName) - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Gets metadata on a pending or completed [Backup][google.spanner.admin.database.v1.Backup].
getBackup(String) - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Gets metadata on a pending or completed [Backup][google.spanner.admin.database.v1.Backup].
getBackup(GetBackupRequest) - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Gets metadata on a pending or completed [Backup][google.spanner.admin.database.v1.Backup].
getBackup() - Method in class com.google.cloud.spanner.BackupId
Returns the backup id.
getBackup(String, String) - Method in interface com.google.cloud.spanner.DatabaseAdminClient
Gets the current state of a Cloud Spanner database backup.
getBackup(String) - Method in class com.google.cloud.spanner.Instance
Returns the backup with the given id on this instance.
getBackup() - Method in class com.google.cloud.spanner.RestoreInfo
The backup source of the restored database.
getBackup(String) - Method in class com.google.cloud.spanner.spi.v1.GapicSpannerRpc
 
getBackup(String) - Method in interface com.google.cloud.spanner.spi.v1.SpannerRpc
Gets the backup with the specified name.
getBackupCallable() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Gets metadata on a pending or completed [Backup][google.spanner.admin.database.v1.Backup].
getBackupCallable() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStub
 
getBackupCallable() - Method in class com.google.cloud.spanner.admin.database.v1.stub.GrpcDatabaseAdminStub
 
getBackupCreateTime() - Method in class com.google.cloud.spanner.RestoreInfo
The create time of the backup for the restore.
getBackupIAMPolicy(String, String) - Method in interface com.google.cloud.spanner.DatabaseAdminClient
Returns the IAM policy for the given backup.
getBackupSettings() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminSettings.Builder
Returns the builder for the settings used for calls to getBackup.
getBackupSettings() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminSettings
Returns the object with the settings used for calls to getBackup.
getBackupSettings() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStubSettings.Builder
Returns the builder for the settings used for calls to getBackup.
getBackupSettings() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStubSettings
Returns the object with the settings used for calls to getBackup.
getBatchClient(DatabaseId) - Method in interface com.google.cloud.spanner.Spanner
Returns a BatchClient to do batch operations on Cloud Spanner databases.
getBatchClient(Database) - Method in class com.google.cloud.spanner.testing.RemoteSpannerHelper
 
getBatchTransactionId() - Method in interface com.google.cloud.spanner.BatchReadOnlyTransaction
Returns a BatchTransactionId to be re-used across several machines/processes.
getBatchUpdateTimeout() - Method in class com.google.cloud.spanner.SpannerOptions.SpannerCallContextTimeoutConfigurator
 
getBigDecimal(int) - Method in class com.google.cloud.spanner.AbstractStructReader
 
getBigDecimal(String) - Method in class com.google.cloud.spanner.AbstractStructReader
 
getBigDecimal(int) - Method in class com.google.cloud.spanner.ForwardingStructReader
 
getBigDecimal(String) - Method in class com.google.cloud.spanner.ForwardingStructReader
 
getBigDecimal(int) - Method in interface com.google.cloud.spanner.StructReader
Returns the value of a non-NULL column with type Type.numeric().
getBigDecimal(String) - Method in interface com.google.cloud.spanner.StructReader
Returns the value of a non-NULL column with type Type.numeric().
getBigDecimalInternal(int) - Method in class com.google.cloud.spanner.AbstractStructReader
 
getBigDecimalList(int) - Method in class com.google.cloud.spanner.AbstractStructReader
 
getBigDecimalList(String) - Method in class com.google.cloud.spanner.AbstractStructReader
 
getBigDecimalList(int) - Method in class com.google.cloud.spanner.ForwardingStructReader
 
getBigDecimalList(String) - Method in class com.google.cloud.spanner.ForwardingStructReader
 
getBigDecimalList(int) - Method in interface com.google.cloud.spanner.StructReader
Returns the value of a non-NULL column with type Type.array(Type.numeric()).
getBigDecimalList(String) - Method in interface com.google.cloud.spanner.StructReader
Returns the value of a non-NULL column with type Type.array(Type.numeric()).
getBigDecimalListInternal(int) - Method in class com.google.cloud.spanner.AbstractStructReader
 
getBool() - Method in class com.google.cloud.spanner.Value
Returns the value of a BOOL-typed instance.
getBoolArray() - Method in class com.google.cloud.spanner.Value
Returns the value of an ARRAY<BOOL>-typed instance.
getBoolean(int) - Method in class com.google.cloud.spanner.AbstractStructReader
 
getBoolean(String) - Method in class com.google.cloud.spanner.AbstractStructReader
 
getBoolean(int) - Method in class com.google.cloud.spanner.ForwardingStructReader
 
getBoolean(String) - Method in class com.google.cloud.spanner.ForwardingStructReader
 
getBoolean(int) - Method in interface com.google.cloud.spanner.StructReader
Returns the value of a non-NULL column with type Type.bool().
getBoolean(String) - Method in interface com.google.cloud.spanner.StructReader
Returns the value of a non-NULL column with type Type.bool().
getBooleanArray(int) - Method in class com.google.cloud.spanner.AbstractStructReader
 
getBooleanArray(String) - Method in class com.google.cloud.spanner.AbstractStructReader
 
getBooleanArray(int) - Method in class com.google.cloud.spanner.ForwardingStructReader
 
getBooleanArray(String) - Method in class com.google.cloud.spanner.ForwardingStructReader
 
getBooleanArray(int) - Method in interface com.google.cloud.spanner.StructReader
Returns the value of a non-NULL column with type Type.array(Type.bool()).
getBooleanArray(String) - Method in interface com.google.cloud.spanner.StructReader
Returns the value of a non-NULL column with type Type.array(Type.bool()).
getBooleanArrayInternal(int) - Method in class com.google.cloud.spanner.AbstractStructReader
 
getBooleanInternal(int) - Method in class com.google.cloud.spanner.AbstractStructReader
 
getBooleanList(int) - Method in class com.google.cloud.spanner.AbstractStructReader
 
getBooleanList(String) - Method in class com.google.cloud.spanner.AbstractStructReader
 
getBooleanList(int) - Method in class com.google.cloud.spanner.ForwardingStructReader
 
getBooleanList(String) - Method in class com.google.cloud.spanner.ForwardingStructReader
 
getBooleanList(int) - Method in interface com.google.cloud.spanner.StructReader
Returns the value of a non-NULL column with type Type.array(Type.bool()).
getBooleanList(String) - Method in interface com.google.cloud.spanner.StructReader
Returns the value of a non-NULL column with type Type.array(Type.bool()).
getBooleanListInternal(int) - Method in class com.google.cloud.spanner.AbstractStructReader
 
getBytes(int) - Method in class com.google.cloud.spanner.AbstractStructReader
 
getBytes(String) - Method in class com.google.cloud.spanner.AbstractStructReader
 
getBytes(int) - Method in class com.google.cloud.spanner.ForwardingStructReader
 
getBytes(String) - Method in class com.google.cloud.spanner.ForwardingStructReader
 
getBytes(int) - Method in interface com.google.cloud.spanner.StructReader
Returns the value of a non-NULL column with type Type.bytes().
getBytes(String) - Method in interface com.google.cloud.spanner.StructReader
Returns the value of a non-NULL column with type Type.bytes().
getBytes() - Method in class com.google.cloud.spanner.Value
Returns the value of a BYTES-typed instance.
getBytesArray() - Method in class com.google.cloud.spanner.Value
Returns the value of an ARRAY<BYTES>-typed instance.
getBytesInternal(int) - Method in class com.google.cloud.spanner.AbstractStructReader
 
getBytesList(int) - Method in class com.google.cloud.spanner.AbstractStructReader
 
getBytesList(String) - Method in class com.google.cloud.spanner.AbstractStructReader
 
getBytesList(int) - Method in class com.google.cloud.spanner.ForwardingStructReader
 
getBytesList(String) - Method in class com.google.cloud.spanner.ForwardingStructReader
 
getBytesList(int) - Method in interface com.google.cloud.spanner.StructReader
Returns the value of a non-NULL column with type Type.array(Type.bytes()).
getBytesList(String) - Method in interface com.google.cloud.spanner.StructReader
Returns the value of a non-NULL column with type Type.array(Type.bytes()).
getBytesListInternal(int) - Method in class com.google.cloud.spanner.AbstractStructReader
 
getCallCredentials() - Method in interface com.google.cloud.spanner.SpannerOptions.CallCredentialsProvider
Return the CallCredentials to use for a gRPC call.
getCallCredentialsProvider() - Method in class com.google.cloud.spanner.SpannerOptions
 
getChannelConfigurator() - Method in class com.google.cloud.spanner.SpannerOptions
 
getChannelProvider() - Method in class com.google.cloud.spanner.SpannerOptions
 
getClient() - Method in class com.google.cloud.spanner.testing.RemoteSpannerHelper
 
getClientSideStatementType() - Method in interface com.google.cloud.spanner.connection.StatementResult
 
getCode() - Method in class com.google.cloud.spanner.Type
Returns the type code corresponding to this type.
getColumnCount() - Method in class com.google.cloud.spanner.AbstractStructReader
 
getColumnCount() - Method in class com.google.cloud.spanner.ForwardingStructReader
 
getColumnCount() - Method in interface com.google.cloud.spanner.StructReader
Returns the number of columns in the underlying data.
getColumnIndex(String) - Method in class com.google.cloud.spanner.AbstractStructReader
 
getColumnIndex(String) - Method in class com.google.cloud.spanner.ForwardingStructReader
 
getColumnIndex(String) - Method in interface com.google.cloud.spanner.StructReader
Returns the index of the column named columnName.
getColumns() - Method in class com.google.cloud.spanner.Mutation
For all types except Mutation.Op.DELETE, returns the columns that this mutation will affect.
getColumnType(int) - Method in class com.google.cloud.spanner.AbstractStructReader
 
getColumnType(String) - Method in class com.google.cloud.spanner.AbstractStructReader
 
getColumnType(int) - Method in class com.google.cloud.spanner.ForwardingStructReader
 
getColumnType(String) - Method in class com.google.cloud.spanner.ForwardingStructReader
 
getColumnType(int) - Method in interface com.google.cloud.spanner.StructReader
Returns the type of a column.
getColumnType(String) - Method in interface com.google.cloud.spanner.StructReader
Returns the type of a column.
getCommitTimeout() - Method in class com.google.cloud.spanner.SpannerOptions.SpannerCallContextTimeoutConfigurator
 
getCommitTimestamp() - Method in interface com.google.cloud.spanner.AsyncRunner
Returns the timestamp at which the transaction committed.
getCommitTimestamp() - Method in class com.google.cloud.spanner.CommitResponse
Returns a Timestamp representing the commit time of the write operation.
getCommitTimestamp() - Method in interface com.google.cloud.spanner.connection.Connection
 
getCommitTimestamp() - Method in interface com.google.cloud.spanner.TransactionManager
Returns the commit timestamp if the transaction committed successfully otherwise it will throw IllegalStateException.
getCommitTimestamp() - Method in interface com.google.cloud.spanner.TransactionRunner
Returns the timestamp at which the transaction committed.
getCompressorName() - Method in class com.google.cloud.spanner.SpannerOptions
 
getConnection() - Method in class com.google.cloud.spanner.connection.ConnectionOptions
Create a new Connection from this ConnectionOptions.
getCreateTime() - Method in class com.google.cloud.spanner.DatabaseInfo
Returns the creation time of the database.
getCredentials() - Method in class com.google.cloud.spanner.connection.ConnectionOptions
The Credentials of this ConnectionOptions.
getCredentialsUrl() - Method in class com.google.cloud.spanner.connection.ConnectionOptions
The credentials URL of this ConnectionOptions
getCurrentRowAsStruct() - Method in class com.google.cloud.spanner.ForwardingResultSet
 
getCurrentRowAsStruct() - Method in interface com.google.cloud.spanner.ResultSet
Creates an immutable version of the row that the result set is positioned over.
getDatabase(DatabaseName) - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Gets the state of a Cloud Spanner database.
getDatabase(String) - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Gets the state of a Cloud Spanner database.
getDatabase(GetDatabaseRequest) - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Gets the state of a Cloud Spanner database.
getDatabase() - Method in class com.google.cloud.spanner.BackupInfo
Returns the id of the database that was used to create the backup.
getDatabase(String, String) - Method in interface com.google.cloud.spanner.DatabaseAdminClient
Gets the current state of a Cloud Spanner database.
getDatabase() - Method in class com.google.cloud.spanner.DatabaseId
Returns the database id.
getDatabase(String) - Method in class com.google.cloud.spanner.Instance
 
getDatabase(String) - Method in class com.google.cloud.spanner.spi.v1.GapicSpannerRpc
 
getDatabase(String) - Method in interface com.google.cloud.spanner.spi.v1.SpannerRpc
 
getDatabaseAdminClient() - Method in interface com.google.cloud.spanner.Spanner
Returns a DatabaseAdminClient to do admin operations on Cloud Spanner databases.
getDatabaseAdminIAMPolicy(String) - Method in class com.google.cloud.spanner.spi.v1.GapicSpannerRpc
 
getDatabaseAdminIAMPolicy(String) - Method in interface com.google.cloud.spanner.spi.v1.SpannerRpc
Gets the IAM policy for the given resource using the DatabaseAdminStub.
getDatabaseAdminStubSettings() - Method in class com.google.cloud.spanner.SpannerOptions
 
getDatabaseAdminStubSettingsBuilder() - Method in class com.google.cloud.spanner.SpannerOptions.Builder
Returns the DatabaseAdminStubSettings.Builder that will be used to build the SpannerRpc.
getDatabaseCallable() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Gets the state of a Cloud Spanner database.
getDatabaseCallable() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStub
 
getDatabaseCallable() - Method in class com.google.cloud.spanner.admin.database.v1.stub.GrpcDatabaseAdminStub
 
getDatabaseClient(DatabaseId) - Method in interface com.google.cloud.spanner.Spanner
Returns a DatabaseClient for the given database.
getDatabaseClient(Database) - Method in class com.google.cloud.spanner.testing.RemoteSpannerHelper
 
getDatabaseDdl(DatabaseName) - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Returns the schema of a Cloud Spanner database as a list of formatted DDL statements.
getDatabaseDdl(String) - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Returns the schema of a Cloud Spanner database as a list of formatted DDL statements.
getDatabaseDdl(GetDatabaseDdlRequest) - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Returns the schema of a Cloud Spanner database as a list of formatted DDL statements.
getDatabaseDdl(String, String) - Method in interface com.google.cloud.spanner.DatabaseAdminClient
Returns the schema of a Cloud Spanner database as a list of formatted DDL statements.
getDatabaseDdl(String) - Method in class com.google.cloud.spanner.spi.v1.GapicSpannerRpc
 
getDatabaseDdl(String) - Method in interface com.google.cloud.spanner.spi.v1.SpannerRpc
 
getDatabaseDdlCallable() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Returns the schema of a Cloud Spanner database as a list of formatted DDL statements.
getDatabaseDdlCallable() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStub
 
getDatabaseDdlCallable() - Method in class com.google.cloud.spanner.admin.database.v1.stub.GrpcDatabaseAdminStub
 
getDatabaseDdlSettings() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminSettings.Builder
Returns the builder for the settings used for calls to getDatabaseDdl.
getDatabaseDdlSettings() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminSettings
Returns the object with the settings used for calls to getDatabaseDdl.
getDatabaseDdlSettings() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStubSettings.Builder
Returns the builder for the settings used for calls to getDatabaseDdl.
getDatabaseDdlSettings() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStubSettings
Returns the object with the settings used for calls to getDatabaseDdl.
getDatabaseErrorDuringRetry() - Method in exception com.google.cloud.spanner.AbortedDueToConcurrentModificationException
 
getDatabaseIAMPolicy(String, String) - Method in interface com.google.cloud.spanner.DatabaseAdminClient
Returns the IAM policy for the given database.
getDatabaseId() - Method in class com.google.cloud.spanner.connection.ConnectionOptions
The Spanner DatabaseId that this ConnectionOptions will connect to
getDatabaseName() - Method in class com.google.cloud.spanner.connection.ConnectionOptions
The Spanner database name that this ConnectionOptions will connect to
getDatabaseSettings() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminSettings.Builder
Returns the builder for the settings used for calls to getDatabase.
getDatabaseSettings() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminSettings
Returns the object with the settings used for calls to getDatabase.
getDatabaseSettings() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStubSettings.Builder
Returns the builder for the settings used for calls to getDatabase.
getDatabaseSettings() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStubSettings
Returns the object with the settings used for calls to getDatabase.
getDate(int) - Method in class com.google.cloud.spanner.AbstractStructReader
 
getDate(String) - Method in class com.google.cloud.spanner.AbstractStructReader
 
getDate(int) - Method in class com.google.cloud.spanner.ForwardingStructReader
 
getDate(String) - Method in class com.google.cloud.spanner.ForwardingStructReader
 
getDate(int) - Method in interface com.google.cloud.spanner.StructReader
Returns the value of a non-NULL column with type Type.date().
getDate(String) - Method in interface com.google.cloud.spanner.StructReader
Returns the value of a non-NULL column with type Type.date().
getDate() - Method in class com.google.cloud.spanner.Value
Returns the value of a DATE-typed instance.
getDateArray() - Method in class com.google.cloud.spanner.Value
Returns the value of an ARRAY<DATE>-typed instance.
getDateInternal(int) - Method in class com.google.cloud.spanner.AbstractStructReader
 
getDateList(int) - Method in class com.google.cloud.spanner.AbstractStructReader
 
getDateList(String) - Method in class com.google.cloud.spanner.AbstractStructReader
 
getDateList(int) - Method in class com.google.cloud.spanner.ForwardingStructReader
 
getDateList(String) - Method in class com.google.cloud.spanner.ForwardingStructReader
 
getDateList(int) - Method in interface com.google.cloud.spanner.StructReader
Returns the value of a non-NULL column with type Type.array(Type.date()).
getDateList(String) - Method in interface com.google.cloud.spanner.StructReader
Returns the value of a non-NULL column with type Type.array(Type.date()).
getDateListInternal(int) - Method in class com.google.cloud.spanner.AbstractStructReader
 
getDdl() - Method in class com.google.cloud.spanner.Database
Returns the schema of a Cloud Spanner database as a list of formatted DDL statements.
getDefaultEndpoint() - Static method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminSettings
Returns the default service endpoint.
getDefaultEndpoint() - Static method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStubSettings
Returns the default service endpoint.
getDefaultEndpoint() - Static method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminSettings
Returns the default service endpoint.
getDefaultEndpoint() - Static method in class com.google.cloud.spanner.admin.instance.v1.stub.InstanceAdminStubSettings
Returns the default service endpoint.
getDefaultEndpoint() - Static method in class com.google.cloud.spanner.v1.SpannerSettings
Returns the default service endpoint.
getDefaultEndpoint() - Static method in class com.google.cloud.spanner.v1.stub.SpannerStubSettings
Returns the default service endpoint.
getDefaultGrpcTransportOptions() - Static method in class com.google.cloud.spanner.SpannerOptions
 
getDefaultHost() - Method in class com.google.cloud.spanner.SpannerOptions
 
getDefaultInstance() - Static method in class com.google.cloud.spanner.PartitionOptions
 
getDefaultInstance() - Static method in class com.google.cloud.spanner.SpannerOptions
Returns default instance of SpannerOptions.
getDefaultProjectId(Credentials) - Static method in class com.google.cloud.spanner.connection.ConnectionOptions
Gets the default project-id for the current environment as defined by ServiceOptions.getDefaultProjectId(), and if none could be found, the project-id of the given credentials if it contains any.
getDefaultQueryOptions(DatabaseId) - Method in class com.google.cloud.spanner.SpannerOptions
Returns the default query options to use for the specific database.
getDefaultServiceScopes() - Static method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminSettings
Returns the default service scopes.
getDefaultServiceScopes() - Static method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStubSettings
Returns the default service scopes.
getDefaultServiceScopes() - Static method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminSettings
Returns the default service scopes.
getDefaultServiceScopes() - Static method in class com.google.cloud.spanner.admin.instance.v1.stub.InstanceAdminStubSettings
Returns the default service scopes.
getDefaultServiceScopes() - Static method in class com.google.cloud.spanner.v1.SpannerSettings
Returns the default service scopes.
getDefaultServiceScopes() - Static method in class com.google.cloud.spanner.v1.stub.SpannerStubSettings
Returns the default service scopes.
getDefaultValue() - Method in class com.google.cloud.spanner.connection.ConnectionOptions.ConnectionProperty
 
getDescription() - Method in class com.google.cloud.spanner.connection.ConnectionOptions.ConnectionProperty
 
getDisplayName() - Method in class com.google.cloud.spanner.InstanceConfigInfo
Returns the display name of this instance config.
getDisplayName() - Method in class com.google.cloud.spanner.InstanceInfo
Returns the display name of the instance.
getDouble(int) - Method in class com.google.cloud.spanner.AbstractStructReader
 
getDouble(String) - Method in class com.google.cloud.spanner.AbstractStructReader
 
getDouble(int) - Method in class com.google.cloud.spanner.ForwardingStructReader
 
getDouble(String) - Method in class com.google.cloud.spanner.ForwardingStructReader
 
getDouble(int) - Method in interface com.google.cloud.spanner.StructReader
Returns the value of a non-NULL column with type Type.float64().
getDouble(String) - Method in interface com.google.cloud.spanner.StructReader
Returns the value of a non-NULL column with type Type.float64().
getDoubleArray(int) - Method in class com.google.cloud.spanner.AbstractStructReader
 
getDoubleArray(String) - Method in class com.google.cloud.spanner.AbstractStructReader
 
getDoubleArray(int) - Method in class com.google.cloud.spanner.ForwardingStructReader
 
getDoubleArray(String) - Method in class com.google.cloud.spanner.ForwardingStructReader
 
getDoubleArray(int) - Method in interface com.google.cloud.spanner.StructReader
Returns the value of a non-NULL column with type Type.array(Type.float64()).
getDoubleArray(String) - Method in interface com.google.cloud.spanner.StructReader
Returns the value of a non-NULL column with type Type.array(Type.float64()).
getDoubleArrayInternal(int) - Method in class com.google.cloud.spanner.AbstractStructReader
 
getDoubleInternal(int) - Method in class com.google.cloud.spanner.AbstractStructReader
 
getDoubleList(int) - Method in class com.google.cloud.spanner.AbstractStructReader
 
getDoubleList(String) - Method in class com.google.cloud.spanner.AbstractStructReader
 
getDoubleList(int) - Method in class com.google.cloud.spanner.ForwardingStructReader
 
getDoubleList(String) - Method in class com.google.cloud.spanner.ForwardingStructReader
 
getDoubleList(int) - Method in interface com.google.cloud.spanner.StructReader
Returns the value of a non-NULL column with type Type.array(Type.float64()).
getDoubleList(String) - Method in interface com.google.cloud.spanner.StructReader
Returns the value of a non-NULL column with type Type.array(Type.float64()).
getDoubleListInternal(int) - Method in class com.google.cloud.spanner.AbstractStructReader
 
getEnd() - Method in class com.google.cloud.spanner.KeyRange
Returns the end key of the range.
getEndpoint() - Method in class com.google.cloud.spanner.SpannerOptions
 
getErrorCode() - Method in exception com.google.cloud.spanner.SpannerException
Returns the error code associated with this exception.
getExactStaleness(TimeUnit) - Method in class com.google.cloud.spanner.TimestampBound
Returns the exact staleness, in the units requested, at which reads will be performed.
getExecuteQueryTimeout() - Method in class com.google.cloud.spanner.SpannerOptions.SpannerCallContextTimeoutConfigurator
 
getExecuteUpdateTimeout() - Method in class com.google.cloud.spanner.SpannerOptions.SpannerCallContextTimeoutConfigurator
 
getExpireTime() - Method in class com.google.cloud.spanner.BackupInfo
Returns the expire time of the backup.
getFieldIndex(String) - Method in class com.google.cloud.spanner.Type
Returns the index of the field named fieldName in this STRUCT type.
getFloat64() - Method in class com.google.cloud.spanner.Value
Returns the value of a FLOAT64-typed instance.
getFloat64Array() - Method in class com.google.cloud.spanner.Value
Returns the value of an ARRAY<FLOAT64>-typed instance.
getGrpcStatusCode() - Method in enum com.google.cloud.spanner.ErrorCode
 
getHost() - Method in class com.google.cloud.spanner.connection.ConnectionOptions
The host and port number that this ConnectionOptions will connect to
getIamPolicy(ResourceName) - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Gets the access control policy for a database or backup resource.
getIamPolicy(String) - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Gets the access control policy for a database or backup resource.
getIamPolicy(GetIamPolicyRequest) - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Gets the access control policy for a database or backup resource.
getIamPolicy(ResourceName) - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminClient
Gets the access control policy for an instance resource.
getIamPolicy(String) - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminClient
Gets the access control policy for an instance resource.
getIamPolicy(GetIamPolicyRequest) - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminClient
Gets the access control policy for an instance resource.
getIAMPolicy() - Method in class com.google.cloud.spanner.Backup
Returns the IAM Policy for this backup.
getIAMPolicy() - Method in class com.google.cloud.spanner.Database
Returns the IAM Policy for this database.
getIAMPolicy() - Method in class com.google.cloud.spanner.Instance
Returns the IAM Policy for this instance.
getIamPolicyCallable() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Gets the access control policy for a database or backup resource.
getIamPolicyCallable() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStub
 
getIamPolicyCallable() - Method in class com.google.cloud.spanner.admin.database.v1.stub.GrpcDatabaseAdminStub
 
getIamPolicyCallable() - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminClient
Gets the access control policy for an instance resource.
getIamPolicyCallable() - Method in class com.google.cloud.spanner.admin.instance.v1.stub.GrpcInstanceAdminStub
 
getIamPolicyCallable() - Method in class com.google.cloud.spanner.admin.instance.v1.stub.InstanceAdminStub
 
getIamPolicySettings() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminSettings.Builder
Returns the builder for the settings used for calls to getIamPolicy.
getIamPolicySettings() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminSettings
Returns the object with the settings used for calls to getIamPolicy.
getIamPolicySettings() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStubSettings.Builder
Returns the builder for the settings used for calls to getIamPolicy.
getIamPolicySettings() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStubSettings
Returns the object with the settings used for calls to getIamPolicy.
getIamPolicySettings() - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminSettings.Builder
Returns the builder for the settings used for calls to getIamPolicy.
getIamPolicySettings() - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminSettings
Returns the object with the settings used for calls to getIamPolicy.
getIamPolicySettings() - Method in class com.google.cloud.spanner.admin.instance.v1.stub.InstanceAdminStubSettings.Builder
Returns the builder for the settings used for calls to getIamPolicy.
getIamPolicySettings() - Method in class com.google.cloud.spanner.admin.instance.v1.stub.InstanceAdminStubSettings
Returns the object with the settings used for calls to getIamPolicy.
getId() - Method in class com.google.cloud.spanner.BackupInfo
Returns the backup id.
getId() - Method in class com.google.cloud.spanner.DatabaseInfo
Returns the database id.
getId() - Method in class com.google.cloud.spanner.InstanceConfigInfo
 
getId() - Method in class com.google.cloud.spanner.InstanceInfo
Returns the identifier of the instance.
getInstance(InstanceName) - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminClient
Gets information about a particular instance.
getInstance(String) - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminClient
Gets information about a particular instance.
getInstance(GetInstanceRequest) - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminClient
Gets information about a particular instance.
getInstance(String) - Method in interface com.google.cloud.spanner.InstanceAdminClient
Gets an instance.
getInstance() - Method in class com.google.cloud.spanner.InstanceId
Returns the instance ID.
getInstance(String) - Method in class com.google.cloud.spanner.spi.v1.GapicSpannerRpc
 
getInstance(String) - Method in interface com.google.cloud.spanner.spi.v1.SpannerRpc
 
getInstanceAdminClient() - Method in interface com.google.cloud.spanner.Spanner
Returns an InstanceAdminClient to do admin operations on Cloud Spanner instances.
getInstanceAdminIAMPolicy(String) - Method in class com.google.cloud.spanner.spi.v1.GapicSpannerRpc
 
getInstanceAdminIAMPolicy(String) - Method in interface com.google.cloud.spanner.spi.v1.SpannerRpc
Gets the IAM policy for the given resource using the InstanceAdminStub.
getInstanceAdminStubSettings() - Method in class com.google.cloud.spanner.SpannerOptions
 
getInstanceAdminStubSettingsBuilder() - Method in class com.google.cloud.spanner.SpannerOptions.Builder
Returns the InstanceAdminStubSettings.Builder that will be used to build the SpannerRpc.
getInstanceCallable() - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminClient
Gets information about a particular instance.
getInstanceCallable() - Method in class com.google.cloud.spanner.admin.instance.v1.stub.GrpcInstanceAdminStub
 
getInstanceCallable() - Method in class com.google.cloud.spanner.admin.instance.v1.stub.InstanceAdminStub
 
getInstanceConfig(InstanceConfigName) - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminClient
Gets information about a particular instance configuration.
getInstanceConfig(String) - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminClient
Gets information about a particular instance configuration.
getInstanceConfig(GetInstanceConfigRequest) - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminClient
Gets information about a particular instance configuration.
getInstanceConfig(String) - Method in interface com.google.cloud.spanner.InstanceAdminClient
Gets an instance config.
getInstanceConfig() - Method in class com.google.cloud.spanner.InstanceConfigId
Returns id of this instance config.
getInstanceConfig(String) - Method in class com.google.cloud.spanner.spi.v1.GapicSpannerRpc
 
getInstanceConfig(String) - Method in interface com.google.cloud.spanner.spi.v1.SpannerRpc
 
getInstanceConfigCallable() - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminClient
Gets information about a particular instance configuration.
getInstanceConfigCallable() - Method in class com.google.cloud.spanner.admin.instance.v1.stub.GrpcInstanceAdminStub
 
getInstanceConfigCallable() - Method in class com.google.cloud.spanner.admin.instance.v1.stub.InstanceAdminStub
 
getInstanceConfigId() - Method in class com.google.cloud.spanner.InstanceInfo
Returns the identifier of the instance configuration.
getInstanceConfigSettings() - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminSettings.Builder
Returns the builder for the settings used for calls to getInstanceConfig.
getInstanceConfigSettings() - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminSettings
Returns the object with the settings used for calls to getInstanceConfig.
getInstanceConfigSettings() - Method in class com.google.cloud.spanner.admin.instance.v1.stub.InstanceAdminStubSettings.Builder
Returns the builder for the settings used for calls to getInstanceConfig.
getInstanceConfigSettings() - Method in class com.google.cloud.spanner.admin.instance.v1.stub.InstanceAdminStubSettings
Returns the object with the settings used for calls to getInstanceConfig.
getInstanceIAMPolicy(String) - Method in interface com.google.cloud.spanner.InstanceAdminClient
Returns the IAM policy for the given instance.
getInstanceId() - Method in class com.google.cloud.spanner.BackupId
Returns the instance id for this backup.
getInstanceId() - Method in class com.google.cloud.spanner.BackupInfo
Returns the id of the instance that the backup belongs to.
getInstanceId() - Method in class com.google.cloud.spanner.connection.ConnectionOptions
The Spanner Instance ID that this ConnectionOptions will connect to
getInstanceId() - Method in class com.google.cloud.spanner.DatabaseId
Returns the instance id for this databse.
getInstanceId() - Method in class com.google.cloud.spanner.testing.RemoteSpannerHelper
 
getInstanceSettings() - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminSettings.Builder
Returns the builder for the settings used for calls to getInstance.
getInstanceSettings() - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminSettings
Returns the object with the settings used for calls to getInstance.
getInstanceSettings() - Method in class com.google.cloud.spanner.admin.instance.v1.stub.InstanceAdminStubSettings.Builder
Returns the builder for the settings used for calls to getInstance.
getInstanceSettings() - Method in class com.google.cloud.spanner.admin.instance.v1.stub.InstanceAdminStubSettings
Returns the object with the settings used for calls to getInstance.
getInt64() - Method in class com.google.cloud.spanner.Value
Returns the value of a INT64-typed instance.
getInt64Array() - Method in class com.google.cloud.spanner.Value
Returns the value of an ARRAY<INT64>-typed instance.
getInterceptorProvider() - Method in class com.google.cloud.spanner.SpannerOptions
 
getInterceptors() - Method in class com.google.cloud.spanner.spi.v1.SpannerInterceptorProvider
 
getKeepAliveIntervalMinutes() - Method in class com.google.cloud.spanner.SessionPoolOptions
 
getKeys() - Method in class com.google.cloud.spanner.KeySet
Returns the keys in this set.
getKeySet() - Method in class com.google.cloud.spanner.Mutation
For Mutation.Op.DELETE mutations, returns the key set that defines the rows to be deleted.
getLabels() - Method in class com.google.cloud.spanner.InstanceInfo
Returns the cloud labels attached to this instance.
getLong(int) - Method in class com.google.cloud.spanner.AbstractStructReader
 
getLong(String) - Method in class com.google.cloud.spanner.AbstractStructReader
 
getLong(int) - Method in class com.google.cloud.spanner.ForwardingStructReader
 
getLong(String) - Method in class com.google.cloud.spanner.ForwardingStructReader
 
getLong(int) - Method in interface com.google.cloud.spanner.StructReader
Returns the value of a non-NULL column with type Type.int64().
getLong(String) - Method in interface com.google.cloud.spanner.StructReader
Returns the value of a non-NULL column with type Type.int64().
getLongArray(int) - Method in class com.google.cloud.spanner.AbstractStructReader
 
getLongArray(String) - Method in class com.google.cloud.spanner.AbstractStructReader
 
getLongArray(int) - Method in class com.google.cloud.spanner.ForwardingStructReader
 
getLongArray(String) - Method in class com.google.cloud.spanner.ForwardingStructReader
 
getLongArray(int) - Method in interface com.google.cloud.spanner.StructReader
Returns the value of a non-NULL column with type Type.array(Type.int64()).
getLongArray(String) - Method in interface com.google.cloud.spanner.StructReader
Returns the value of a non-NULL column with type Type.array(Type.int64()).
getLongArrayInternal(int) - Method in class com.google.cloud.spanner.AbstractStructReader
 
getLongInternal(int) - Method in class com.google.cloud.spanner.AbstractStructReader
 
getLongList(int) - Method in class com.google.cloud.spanner.AbstractStructReader
 
getLongList(String) - Method in class com.google.cloud.spanner.AbstractStructReader
 
getLongList(int) - Method in class com.google.cloud.spanner.ForwardingStructReader
 
getLongList(String) - Method in class com.google.cloud.spanner.ForwardingStructReader
 
getLongList(int) - Method in interface com.google.cloud.spanner.StructReader
Returns the value of a non-NULL column with type Type.array(Type.int64()).
getLongList(String) - Method in interface com.google.cloud.spanner.StructReader
Returns the value of a non-NULL column with type Type.array(Type.int64()).
getLongListInternal(int) - Method in class com.google.cloud.spanner.AbstractStructReader
 
getMaxIdleSessions() - Method in class com.google.cloud.spanner.SessionPoolOptions
 
getMaxPartitions() - Method in class com.google.cloud.spanner.PartitionOptions
Returns the maximum number of partitions to be created.
getMaxSessions() - Method in class com.google.cloud.spanner.SessionPoolOptions
 
getMaxStaleness(TimeUnit) - Method in class com.google.cloud.spanner.TimestampBound
Returns the maximum staleness, in the units requested, at which reads will be performed.
getMetadata() - Method in class com.google.cloud.spanner.Operation
Returns the metadata returned by the last refresh of this operation.
getMinReadTimestamp() - Method in class com.google.cloud.spanner.TimestampBound
Returns the minimum timestamp at which reads will be performed.
getMinSessions() - Method in class com.google.cloud.spanner.SessionPoolOptions
 
getMode() - Method in class com.google.cloud.spanner.TimestampBound
 
getName() - Method in class com.google.cloud.spanner.BackupId
Returns the name of this backup.
getName() - Method in class com.google.cloud.spanner.connection.ConnectionOptions.ConnectionProperty
 
getName() - Method in class com.google.cloud.spanner.DatabaseId
Returns the name of this database.
getName() - Method in class com.google.cloud.spanner.InstanceConfigId
Returns the name of the instance config.
getName() - Method in class com.google.cloud.spanner.InstanceId
Returns the name of the instance.
getName() - Method in class com.google.cloud.spanner.Operation
Returns the name of the operation.
getName() - Method in interface com.google.cloud.spanner.Session
Returns the resource name associated with this session.
getName() - Method in class com.google.cloud.spanner.Type.StructField
 
getNextPageToken() - Method in class com.google.cloud.spanner.spi.v1.SpannerRpc.Paginated
Returns the token to use in the request for the next page, or null if this is the last page.
getNodeCount() - Method in class com.google.cloud.spanner.InstanceInfo
Returns the node count of the instance.
getNoResultAsync() - Method in interface com.google.cloud.spanner.connection.AsyncStatementResult
Returns a future that tracks the progress of a statement that returns no result.
getNumChannels() - Method in class com.google.cloud.spanner.connection.ConnectionOptions
The number of channels to use for the connection.
getNumChannels() - Method in class com.google.cloud.spanner.SpannerOptions
 
getNumeric() - Method in class com.google.cloud.spanner.Value
Returns the value of a NUMERIC-typed instance.
getNumericArray() - Method in class com.google.cloud.spanner.Value
Returns the value of an ARRAY<NUMERIC>-typed instance.
getOperation(String) - Method in interface com.google.cloud.spanner.DatabaseAdminClient
Gets the specified long-running operation.
getOperation(String) - Method in interface com.google.cloud.spanner.InstanceAdminClient
Gets the specified long-running operation.
getOperation() - Method in class com.google.cloud.spanner.Mutation
Returns the type of operation that this mutation will perform.
getOperation(String) - Method in class com.google.cloud.spanner.spi.v1.GapicSpannerRpc
 
getOperation(String) - Method in interface com.google.cloud.spanner.spi.v1.SpannerRpc
Retrieves a long running operation.
getOperationsClient() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Returns the OperationsClient that can be used to query the status of a long-running operation returned by another API method call.
getOperationsClient() - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminClient
Returns the OperationsClient that can be used to query the status of a long-running operation returned by another API method call.
getOperationsStub() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStub
 
getOperationsStub() - Method in class com.google.cloud.spanner.admin.database.v1.stub.GrpcDatabaseAdminStub
 
getOperationsStub() - Method in class com.google.cloud.spanner.admin.instance.v1.stub.GrpcInstanceAdminStub
 
getOperationsStub() - Method in class com.google.cloud.spanner.admin.instance.v1.stub.InstanceAdminStub
 
getOperationsStub() - Method in class com.google.cloud.spanner.v1.stub.GrpcSpannerStub
 
getOptimizerVersion() - Method in interface com.google.cloud.spanner.connection.Connection
Gets the current query optimizer version of this connection.
getOptimizerVersion() - Method in interface com.google.cloud.spanner.SpannerOptions.SpannerEnvironment
The optimizer version to use.
getOptions() - Method in class com.google.cloud.spanner.testing.RemoteSpannerHelper
 
getOrNull(ApiFuture<T>) - Static method in class com.google.cloud.spanner.SpannerApiFutures
 
getParameters() - Method in class com.google.cloud.spanner.Statement
Returns the parameters bound to this Statement.
getPartitionedDmlRetrySettings() - Method in class com.google.cloud.spanner.spi.v1.GapicSpannerRpc
 
getPartitionedDmlRetrySettings() - Method in interface com.google.cloud.spanner.spi.v1.SpannerRpc
 
getPartitionedDmlTimeout() - Method in class com.google.cloud.spanner.SpannerOptions
 
getPartitionQueryTimeout() - Method in class com.google.cloud.spanner.SpannerOptions.SpannerCallContextTimeoutConfigurator
 
getPartitionReadTimeout() - Method in class com.google.cloud.spanner.SpannerOptions.SpannerCallContextTimeoutConfigurator
 
getPartitionSizeBytes() - Method in class com.google.cloud.spanner.PartitionOptions
Returns the size of the partition in bytes.
getParts() - Method in class com.google.cloud.spanner.Key
Returns the parts in this key.
getPrefetchChunks() - Method in class com.google.cloud.spanner.SpannerOptions
 
getProject() - Method in class com.google.cloud.spanner.InstanceConfigId
Returns project of this instane config.
getProject() - Method in class com.google.cloud.spanner.InstanceId
Returns the ID of the project that owns this instance.
getProjectId() - Method in class com.google.cloud.spanner.connection.ConnectionOptions
The Google Project ID that this ConnectionOptions will connect to
getProto() - Method in class com.google.cloud.spanner.BackupInfo
Returns the raw proto instance that was used to construct this Backup.
getProto() - Method in class com.google.cloud.spanner.DatabaseInfo
Returns the raw proto instance that was used to construct this Database.
getProto() - Method in class com.google.cloud.spanner.RestoreInfo
Returns the raw proto instance that was used to construct this RestoreInfo.
getQueryOptions() - Method in class com.google.cloud.spanner.Statement
Returns the ExecuteSqlRequest.QueryOptions that will be used with this Statement.
getRanges() - Method in class com.google.cloud.spanner.KeySet
Returns the ranges in this set.
getReadOnlyStaleness() - Method in interface com.google.cloud.spanner.connection.Connection
 
getReadTimeout() - Method in class com.google.cloud.spanner.SpannerOptions.SpannerCallContextTimeoutConfigurator
 
getReadTimestamp() - Method in interface com.google.cloud.spanner.connection.Connection
Returns the read timestamp of the current/last TransactionMode.READ_ONLY_TRANSACTION transaction, or the read timestamp of the last query in autocommit mode.
getReadTimestamp() - Method in interface com.google.cloud.spanner.ReadOnlyTransaction
Returns the timestamp chosen to perform reads and queries in this transaction.
getReadTimestamp() - Method in class com.google.cloud.spanner.TimestampBound
Returns the timestamp at which reads will be performed.
getRemoveInactiveSessionAfter() - Method in class com.google.cloud.spanner.SessionPoolOptions
 
getResourceName() - Method in exception com.google.cloud.spanner.SpannerException.ResourceNotFoundException
 
getRestoreInfo() - Method in class com.google.cloud.spanner.DatabaseInfo
Returns the RestoreInfo of the database if any is available, or null if no RestoreInfo is available for this database.
getResult() - Method in class com.google.cloud.spanner.Operation
Returns result of the operation if the operation is complete and had a result.
getResults() - Method in class com.google.cloud.spanner.spi.v1.SpannerRpc.Paginated
Returns the current page of results.
getResultSet() - Method in interface com.google.cloud.spanner.connection.StatementResult
Returns the ResultSet held by this result.
getResultSetAsync() - Method in interface com.google.cloud.spanner.connection.AsyncStatementResult
Returns the AsyncResultSet held by this result.
getResultType() - Method in interface com.google.cloud.spanner.connection.StatementResult
Returns the StatementResult.ResultType of this result.
getRetryDelayInMillis() - Method in exception com.google.cloud.spanner.SpannerException
Return the retry delay for operation in milliseconds.
getRollbackTimeout() - Method in class com.google.cloud.spanner.SpannerOptions.SpannerCallContextTimeoutConfigurator
 
getScopes() - Method in class com.google.cloud.spanner.SpannerOptions
 
getSelector() - Method in enum com.google.cloud.spanner.InstanceInfo.InstanceField
 
getSession(SessionName) - Method in class com.google.cloud.spanner.v1.SpannerClient
Gets a session.
getSession(String) - Method in class com.google.cloud.spanner.v1.SpannerClient
Gets a session.
getSession(GetSessionRequest) - Method in class com.google.cloud.spanner.v1.SpannerClient
Gets a session.
getSessionCallable() - Method in class com.google.cloud.spanner.v1.SpannerClient
Gets a session.
getSessionCallable() - Method in class com.google.cloud.spanner.v1.stub.GrpcSpannerStub
 
getSessionCallable() - Method in class com.google.cloud.spanner.v1.stub.SpannerStub
 
getSessionLabels() - Method in class com.google.cloud.spanner.SpannerOptions
 
getSessionPoolOptions() - Method in class com.google.cloud.spanner.connection.ConnectionOptions
getSessionPoolOptions() - Method in class com.google.cloud.spanner.SpannerOptions
 
getSessionSettings() - Method in class com.google.cloud.spanner.v1.SpannerSettings.Builder
Returns the builder for the settings used for calls to getSession.
getSessionSettings() - Method in class com.google.cloud.spanner.v1.SpannerSettings
Returns the object with the settings used for calls to getSession.
getSessionSettings() - Method in class com.google.cloud.spanner.v1.stub.SpannerStubSettings.Builder
Returns the builder for the settings used for calls to getSession.
getSessionSettings() - Method in class com.google.cloud.spanner.v1.stub.SpannerStubSettings
Returns the object with the settings used for calls to getSession.
getSettings() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
 
getSettings() - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminClient
 
getSettings() - Method in class com.google.cloud.spanner.v1.SpannerClient
 
getSize() - Method in class com.google.cloud.spanner.BackupInfo
Returns the size of the backup in bytes.
getSourceDatabase() - Method in class com.google.cloud.spanner.RestoreInfo
The source database that was used to create the backup.
getSourceType() - Method in class com.google.cloud.spanner.RestoreInfo
The source type of the restore.
getSpannerRpcV1() - Method in class com.google.cloud.spanner.SpannerOptions
 
getSpannerStubSettings() - Method in class com.google.cloud.spanner.SpannerOptions
 
getSpannerStubSettingsBuilder() - Method in class com.google.cloud.spanner.SpannerOptions.Builder
Returns the SpannerStubSettings.Builder that will be used to build the SpannerRpc.
getSql() - Method in class com.google.cloud.spanner.Statement
Returns the current SQL statement text.
getStart() - Method in class com.google.cloud.spanner.KeyRange
Returns the start key of the range.
getStartType() - Method in class com.google.cloud.spanner.KeyRange
Indicates whether the start key is inclusive (CLOSED) or exclusive (OPEN).
getState() - Method in interface com.google.cloud.spanner.AsyncTransactionManager
Returns the state of the transaction.
getState() - Method in class com.google.cloud.spanner.BackupInfo
Returns the state of the backup.
getState() - Method in class com.google.cloud.spanner.DatabaseInfo
Returns the state of the database.
getState() - Method in class com.google.cloud.spanner.InstanceInfo
Returns the current state of the instance.
getState() - Method in interface com.google.cloud.spanner.TransactionManager
Returns the state of the transaction.
getStatementString() - Method in enum com.google.cloud.spanner.connection.AutocommitDmlMode
Use this method to get the correct format for use in a SQL statement.
getStatementString() - Method in enum com.google.cloud.spanner.connection.TransactionMode
Use this method to get the correct format for use in a SQL statement.
getStatementTimeout(TimeUnit) - Method in interface com.google.cloud.spanner.connection.Connection
 
getStats() - Method in class com.google.cloud.spanner.ForwardingResultSet
 
getStats() - Method in interface com.google.cloud.spanner.ResultSet
Returns the ResultSetStats for the query only if the query was executed in either the PLAN or the PROFILE mode via the ReadContext.analyzeQuery(Statement, com.google.cloud.spanner.ReadContext.QueryAnalyzeMode) method or for DML statements in ReadContext#executeQuery(Statement, QueryOption...).
getString(int) - Method in class com.google.cloud.spanner.AbstractStructReader
 
getString(String) - Method in class com.google.cloud.spanner.AbstractStructReader
 
getString(int) - Method in class com.google.cloud.spanner.ForwardingStructReader
 
getString(String) - Method in class com.google.cloud.spanner.ForwardingStructReader
 
getString(int) - Method in interface com.google.cloud.spanner.StructReader
Returns the value of a non-NULL column with type Type.string().
getString(String) - Method in interface com.google.cloud.spanner.StructReader
Returns the value of a non-NULL column with type Type.string().
getString() - Method in class com.google.cloud.spanner.Value
Returns the value of a STRING-typed instance.
getStringArray() - Method in class com.google.cloud.spanner.Value
Returns the value of an ARRAY<STRING>-typed instance.
getStringInternal(int) - Method in class com.google.cloud.spanner.AbstractStructReader
 
getStringList(int) - Method in class com.google.cloud.spanner.AbstractStructReader
 
getStringList(String) - Method in class com.google.cloud.spanner.AbstractStructReader
 
getStringList(int) - Method in class com.google.cloud.spanner.ForwardingStructReader
 
getStringList(String) - Method in class com.google.cloud.spanner.ForwardingStructReader
 
getStringList(int) - Method in interface com.google.cloud.spanner.StructReader
Returns the value of a non-NULL column with type Type.array(Type.string()).
getStringList(String) - Method in interface com.google.cloud.spanner.StructReader
Returns the value of a non-NULL column with type Type.array(Type.string()).
getStringListInternal(int) - Method in class com.google.cloud.spanner.AbstractStructReader
 
getStruct(int) - Method in class com.google.cloud.spanner.Struct
TODO(user) : Consider moving these methods to the StructReader interface once STRUCT-typed columns are supported in ResultSet.
getStruct(String) - Method in class com.google.cloud.spanner.Struct
 
getStruct() - Method in class com.google.cloud.spanner.Value
Returns the value of a STRUCT-typed instance.
getStructFields() - Method in class com.google.cloud.spanner.Type
Returns the fields of this STRUCT type.
getStructInternal(int) - Method in class com.google.cloud.spanner.Struct
 
getStructList(int) - Method in class com.google.cloud.spanner.AbstractStructReader
 
getStructList(String) - Method in class com.google.cloud.spanner.AbstractStructReader
 
getStructList(int) - Method in class com.google.cloud.spanner.ForwardingStructReader
 
getStructList(String) - Method in class com.google.cloud.spanner.ForwardingStructReader
 
getStructList(int) - Method in interface com.google.cloud.spanner.StructReader
Returns the value of a non-NULL column with type Type.array(Type.struct(...)).
getStructList(String) - Method in interface com.google.cloud.spanner.StructReader
Returns the value of a non-NULL column with type Type.array(Type.struct(...)).
getStructListInternal(int) - Method in class com.google.cloud.spanner.AbstractStructReader
 
getStub() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
 
getStub() - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminClient
 
getStub() - Method in class com.google.cloud.spanner.v1.SpannerClient
 
getStubSettingsBuilder() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminSettings.Builder
 
getStubSettingsBuilder() - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminSettings.Builder
 
getStubSettingsBuilder() - Method in class com.google.cloud.spanner.v1.SpannerSettings.Builder
 
getTable() - Method in class com.google.cloud.spanner.Mutation
Returns the name of the table that this mutation will affect.
getTimestamp(int) - Method in class com.google.cloud.spanner.AbstractStructReader
 
getTimestamp(String) - Method in class com.google.cloud.spanner.AbstractStructReader
 
getTimestamp(int) - Method in class com.google.cloud.spanner.ForwardingStructReader
 
getTimestamp(String) - Method in class com.google.cloud.spanner.ForwardingStructReader
 
getTimestamp(int) - Method in interface com.google.cloud.spanner.StructReader
Returns the value of a non-NULL column with type Type.timestamp().
getTimestamp(String) - Method in interface com.google.cloud.spanner.StructReader
Returns the value of a non-NULL column with type Type.timestamp().
getTimestamp() - Method in class com.google.cloud.spanner.Value
Returns the value of a TIMESTAMP-typed instance.
getTimestampArray() - Method in class com.google.cloud.spanner.Value
Returns the value of an ARRAY<TIMESTAMP>-typed instance.
getTimestampInternal(int) - Method in class com.google.cloud.spanner.AbstractStructReader
 
getTimestampList(int) - Method in class com.google.cloud.spanner.AbstractStructReader
 
getTimestampList(String) - Method in class com.google.cloud.spanner.AbstractStructReader
 
getTimestampList(int) - Method in class com.google.cloud.spanner.ForwardingStructReader
 
getTimestampList(String) - Method in class com.google.cloud.spanner.ForwardingStructReader
 
getTimestampList(int) - Method in interface com.google.cloud.spanner.StructReader
Returns the value of a non-NULL column with type Type.array(Type.timestamp()).
getTimestampList(String) - Method in interface com.google.cloud.spanner.StructReader
Returns the value of a non-NULL column with type Type.array(Type.timestamp()).
getTimestampListInternal(int) - Method in class com.google.cloud.spanner.AbstractStructReader
 
getTransactionMode() - Method in interface com.google.cloud.spanner.connection.Connection
 
getTransactionRetryListeners() - Method in interface com.google.cloud.spanner.connection.Connection
 
getType() - Method in class com.google.cloud.spanner.ForwardingStructReader
 
getType() - Method in interface com.google.cloud.spanner.StructReader
Returns the type of the underlying data.
getType() - Method in class com.google.cloud.spanner.Type.StructField
 
getType() - Method in class com.google.cloud.spanner.Value
Returns the type of this value.
getUniqueDatabaseId() - Method in class com.google.cloud.spanner.testing.RemoteSpannerHelper
Returns a database id which is guaranteed to be unique within the context of this environment.
getUpdateCount() - Method in interface com.google.cloud.spanner.connection.StatementResult
Returns the update count held by this result.
getUpdateCountAsync() - Method in interface com.google.cloud.spanner.connection.AsyncStatementResult
Returns the update count held by this result.
getUpdateCounts() - Method in exception com.google.cloud.spanner.SpannerBatchUpdateException
Returns the number of rows affected by each statement that is successfully run.
getUri() - Method in class com.google.cloud.spanner.connection.ConnectionOptions
The URI of this ConnectionOptions
getValidValues() - Method in class com.google.cloud.spanner.connection.ConnectionOptions.ConnectionProperty
 
getValues() - Method in class com.google.cloud.spanner.Mutation
For all types except Mutation.Op.DELETE, returns the values that this mutation will write.
getWarnings() - Method in class com.google.cloud.spanner.connection.ConnectionOptions
Any warnings that were generated while creating the ConnectionOptions instance.
getWriteSessionsFraction() - Method in class com.google.cloud.spanner.SessionPoolOptions
Deprecated.
This value is no longer used. The session pool does not prepare any sessions for read/write transactions. Instead, a transaction will be started by including a BeginTransaction option with the first statement of a transaction. This method may be removed in a future release.
GrpcDatabaseAdminCallableFactory - Class in com.google.cloud.spanner.admin.database.v1.stub
gRPC callable factory implementation for the DatabaseAdmin service API.
GrpcDatabaseAdminCallableFactory() - Constructor for class com.google.cloud.spanner.admin.database.v1.stub.GrpcDatabaseAdminCallableFactory
 
GrpcDatabaseAdminStub - Class in com.google.cloud.spanner.admin.database.v1.stub
gRPC stub implementation for the DatabaseAdmin service API.
GrpcDatabaseAdminStub(DatabaseAdminStubSettings, ClientContext) - Constructor for class com.google.cloud.spanner.admin.database.v1.stub.GrpcDatabaseAdminStub
Constructs an instance of GrpcDatabaseAdminStub, using the given settings.
GrpcDatabaseAdminStub(DatabaseAdminStubSettings, ClientContext, GrpcStubCallableFactory) - Constructor for class com.google.cloud.spanner.admin.database.v1.stub.GrpcDatabaseAdminStub
Constructs an instance of GrpcDatabaseAdminStub, using the given settings.
GrpcInstanceAdminCallableFactory - Class in com.google.cloud.spanner.admin.instance.v1.stub
gRPC callable factory implementation for the InstanceAdmin service API.
GrpcInstanceAdminCallableFactory() - Constructor for class com.google.cloud.spanner.admin.instance.v1.stub.GrpcInstanceAdminCallableFactory
 
GrpcInstanceAdminStub - Class in com.google.cloud.spanner.admin.instance.v1.stub
gRPC stub implementation for the InstanceAdmin service API.
GrpcInstanceAdminStub(InstanceAdminStubSettings, ClientContext) - Constructor for class com.google.cloud.spanner.admin.instance.v1.stub.GrpcInstanceAdminStub
Constructs an instance of GrpcInstanceAdminStub, using the given settings.
GrpcInstanceAdminStub(InstanceAdminStubSettings, ClientContext, GrpcStubCallableFactory) - Constructor for class com.google.cloud.spanner.admin.instance.v1.stub.GrpcInstanceAdminStub
Constructs an instance of GrpcInstanceAdminStub, using the given settings.
GrpcSpannerCallableFactory - Class in com.google.cloud.spanner.v1.stub
gRPC callable factory implementation for the Spanner service API.
GrpcSpannerCallableFactory() - Constructor for class com.google.cloud.spanner.v1.stub.GrpcSpannerCallableFactory
 
GrpcSpannerStub - Class in com.google.cloud.spanner.v1.stub
gRPC stub implementation for the Spanner service API.
GrpcSpannerStub(SpannerStubSettings, ClientContext) - Constructor for class com.google.cloud.spanner.v1.stub.GrpcSpannerStub
Constructs an instance of GrpcSpannerStub, using the given settings.
GrpcSpannerStub(SpannerStubSettings, ClientContext, GrpcStubCallableFactory) - Constructor for class com.google.cloud.spanner.v1.stub.GrpcSpannerStub
Constructs an instance of GrpcSpannerStub, using the given settings.

H

hasBinding(String) - Method in class com.google.cloud.spanner.Statement
Returns true if a binding exists for parameter.
hashCode() - Method in class com.google.cloud.spanner.BackupId
 
hashCode() - Method in class com.google.cloud.spanner.BackupInfo
 
hashCode() - Method in class com.google.cloud.spanner.BatchTransactionId
 
hashCode() - Method in class com.google.cloud.spanner.CommitResponse
 
hashCode() - Method in class com.google.cloud.spanner.connection.ConnectionOptions.ConnectionProperty
 
hashCode() - Method in class com.google.cloud.spanner.DatabaseId
 
hashCode() - Method in class com.google.cloud.spanner.DatabaseInfo
 
hashCode() - Method in class com.google.cloud.spanner.InstanceConfigId
 
hashCode() - Method in class com.google.cloud.spanner.InstanceConfigInfo
 
hashCode() - Method in class com.google.cloud.spanner.InstanceId
 
hashCode() - Method in class com.google.cloud.spanner.InstanceInfo
 
hashCode() - Method in class com.google.cloud.spanner.Key
 
hashCode() - Method in class com.google.cloud.spanner.KeyRange
 
hashCode() - Method in class com.google.cloud.spanner.KeySet
 
hashCode() - Method in class com.google.cloud.spanner.Mutation
 
hashCode() - Method in class com.google.cloud.spanner.Options
 
hashCode() - Method in class com.google.cloud.spanner.Partition
 
hashCode() - Method in class com.google.cloud.spanner.PartitionOptions
 
hashCode() - Method in class com.google.cloud.spanner.Statement
 
hashCode() - Method in class com.google.cloud.spanner.Struct
 
hashCode() - Method in class com.google.cloud.spanner.TimestampBound
 
hashCode() - Method in class com.google.cloud.spanner.Type
 
hashCode() - Method in class com.google.cloud.spanner.Type.StructField
 
hasStatementTimeout() - Method in interface com.google.cloud.spanner.connection.Connection
 

I

initialize() - Method in class com.google.cloud.spanner.AbstractLazyInitializer
Initializes the actual object that should be returned.
initialize() - Method in class com.google.cloud.spanner.LazySpannerInitializer
Initializes a default Spanner instance.
INSTANCE - Static variable in class com.google.cloud.spanner.connection.Connection.InternalMetadataQuery
 
INSTANCE - Static variable in class com.google.cloud.spanner.connection.StatementParser
Singleton instance of StatementParser.
Instance - Class in com.google.cloud.spanner
Represents a Cloud Spanner Instance.
Instance.Builder - Class in com.google.cloud.spanner
Builder of Instance.
InstanceAdminClient - Class in com.google.cloud.spanner.admin.instance.v1
Service Description: Cloud Spanner Instance Admin API
InstanceAdminClient(InstanceAdminSettings) - Constructor for class com.google.cloud.spanner.admin.instance.v1.InstanceAdminClient
Constructs an instance of InstanceAdminClient, using the given settings.
InstanceAdminClient(InstanceAdminStub) - Constructor for class com.google.cloud.spanner.admin.instance.v1.InstanceAdminClient
 
InstanceAdminClient - Interface in com.google.cloud.spanner
Client to do admin operations on Cloud Spanner Instance and Instance Configs.
InstanceAdminClient.ListInstanceConfigsFixedSizeCollection - Class in com.google.cloud.spanner.admin.instance.v1
 
InstanceAdminClient.ListInstanceConfigsPage - Class in com.google.cloud.spanner.admin.instance.v1
 
InstanceAdminClient.ListInstanceConfigsPagedResponse - Class in com.google.cloud.spanner.admin.instance.v1
 
InstanceAdminClient.ListInstancesFixedSizeCollection - Class in com.google.cloud.spanner.admin.instance.v1
 
InstanceAdminClient.ListInstancesPage - Class in com.google.cloud.spanner.admin.instance.v1
 
InstanceAdminClient.ListInstancesPagedResponse - Class in com.google.cloud.spanner.admin.instance.v1
 
InstanceAdminSettings - Class in com.google.cloud.spanner.admin.instance.v1
Settings class to configure an instance of InstanceAdminClient.
InstanceAdminSettings(InstanceAdminSettings.Builder) - Constructor for class com.google.cloud.spanner.admin.instance.v1.InstanceAdminSettings
 
InstanceAdminSettings.Builder - Class in com.google.cloud.spanner.admin.instance.v1
Builder for InstanceAdminSettings.
InstanceAdminStub - Class in com.google.cloud.spanner.admin.instance.v1.stub
Base stub class for the InstanceAdmin service API.
InstanceAdminStub() - Constructor for class com.google.cloud.spanner.admin.instance.v1.stub.InstanceAdminStub
 
InstanceAdminStubSettings - Class in com.google.cloud.spanner.admin.instance.v1.stub
Settings class to configure an instance of InstanceAdminStub.
InstanceAdminStubSettings(InstanceAdminStubSettings.Builder) - Constructor for class com.google.cloud.spanner.admin.instance.v1.stub.InstanceAdminStubSettings
 
InstanceAdminStubSettings.Builder - Class in com.google.cloud.spanner.admin.instance.v1.stub
Builder for InstanceAdminStubSettings.
InstanceConfig - Class in com.google.cloud.spanner
Represents a Cloud Spanner instance config.InstanceConfig adds a layer of service related functionality over InstanceConfigInfo.
InstanceConfig(InstanceConfigId, String, InstanceAdminClient) - Constructor for class com.google.cloud.spanner.InstanceConfig
 
InstanceConfigId - Class in com.google.cloud.spanner
Returns id of a Cloud Spanner instance config.
InstanceConfigInfo - Class in com.google.cloud.spanner
Represents a Cloud Spanner instance config resource.
InstanceConfigInfo(InstanceConfigId, String) - Constructor for class com.google.cloud.spanner.InstanceConfigInfo
 
InstanceId - Class in com.google.cloud.spanner
Represents the resource name of a Cloud Spanner Instance.
InstanceInfo - Class in com.google.cloud.spanner
Represents a Cloud Spanner Instance.
InstanceInfo.Builder - Class in com.google.cloud.spanner
Builder for InstanceInfo.
InstanceInfo.InstanceField - Enum in com.google.cloud.spanner
Represent an updatable field in Cloud Spanner instance.
InstanceInfo.State - Enum in com.google.cloud.spanner
State of the Instance.
InstanceNotFoundException - Exception in com.google.cloud.spanner
Exception thrown by Cloud Spanner when an operation detects that the instance that is being used no longer exists.
int64() - Static method in class com.google.cloud.spanner.Type
Returns the descriptor for the INT64 type: an integral type with the same value domain as a Java long.
int64(Long) - Static method in class com.google.cloud.spanner.Value
Returns an INT64 value.
int64(long) - Static method in class com.google.cloud.spanner.Value
Returns an INT64 value.
int64Array(long[]) - Static method in class com.google.cloud.spanner.Value
Returns an ARRAY<INT64> value.
int64Array(long[], int, int) - Static method in class com.google.cloud.spanner.Value
Returns an ARRAY<INT64> value that takes its elements from a region of an array.
int64Array(Iterable<Long>) - Static method in class com.google.cloud.spanner.Value
Returns an ARRAY<INT64> value.
interceptCall(MethodDescriptor<ReqT, RespT>, CallOptions, Channel) - Method in class com.google.cloud.spanner.spi.v1.SpannerErrorInterceptor
 
invalidate() - Method in class com.google.cloud.spanner.PartitionedDmlTransaction
 
isAll() - Method in class com.google.cloud.spanner.KeySet
Indicates whether the set will retrieve all rows in a table or index.
isAutocommit() - Method in interface com.google.cloud.spanner.connection.Connection
 
isAutocommit() - Method in class com.google.cloud.spanner.connection.ConnectionOptions
The initial autocommit value for connections created by this ConnectionOptions
isAutoThrottleAdministrativeRequests() - Method in class com.google.cloud.spanner.SpannerOptions
 
isBlockIfPoolExhausted() - Method in class com.google.cloud.spanner.SessionPoolOptions
 
isClosed() - Method in interface com.google.cloud.spanner.connection.Connection
 
isClosed() - Method in interface com.google.cloud.spanner.Spanner
 
isClosed() - Method in class com.google.cloud.spanner.spi.v1.GapicSpannerRpc
 
isClosed() - Method in interface com.google.cloud.spanner.spi.v1.SpannerRpc
 
isCommitTimestamp() - Method in class com.google.cloud.spanner.Value
Returns true if this is a commit timestamp value.
isDdlBatchActive() - Method in interface com.google.cloud.spanner.connection.Connection
 
isDdlStatement(String) - Method in class com.google.cloud.spanner.connection.StatementParser
Checks whether the given statement is (probably) a DDL statement.
isDmlBatchActive() - Method in interface com.google.cloud.spanner.connection.Connection
 
isDone() - Method in class com.google.cloud.spanner.Operation
Returns true if the operation is done.
isEmulator() - Method in class com.google.cloud.spanner.testing.RemoteSpannerHelper
Deprecated.
isFailIfPoolExhausted() - Method in class com.google.cloud.spanner.SessionPoolOptions
 
isInTransaction() - Method in interface com.google.cloud.spanner.connection.Connection
 
isNull(String) - Method in class com.google.cloud.spanner.AbstractStructReader
 
isNull(int) - Method in class com.google.cloud.spanner.ForwardingStructReader
 
isNull(String) - Method in class com.google.cloud.spanner.ForwardingStructReader
 
isNull(int) - Method in interface com.google.cloud.spanner.StructReader
Returns true if a column contains a NULL value.
isNull(String) - Method in interface com.google.cloud.spanner.StructReader
Returns true if a column contains a NULL value.
isNull() - Method in class com.google.cloud.spanner.Value
Returns true if this instance represents a NULL value.
isQuery(String) - Method in class com.google.cloud.spanner.connection.StatementParser
Checks whether the given statement is (probably) a SELECT query.
isReadOnly() - Method in interface com.google.cloud.spanner.connection.Connection
 
isReadOnly() - Method in class com.google.cloud.spanner.connection.ConnectionOptions
The initial readonly value for connections created by this ConnectionOptions
isReady() - Method in class com.google.cloud.spanner.Backup
Returns true if this backup is ready to use.
IsRetryableInternalError - Class in com.google.cloud.spanner
 
IsRetryableInternalError() - Constructor for class com.google.cloud.spanner.IsRetryableInternalError
 
isRetryAbortsInternally() - Method in interface com.google.cloud.spanner.connection.Connection
 
isRetryAbortsInternally() - Method in class com.google.cloud.spanner.connection.ConnectionOptions
The initial retryAbortsInternally value for connections created by this ConnectionOptions
isShutdown() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
 
isShutdown() - Method in class com.google.cloud.spanner.admin.database.v1.stub.GrpcDatabaseAdminStub
 
isShutdown() - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminClient
 
isShutdown() - Method in class com.google.cloud.spanner.admin.instance.v1.stub.GrpcInstanceAdminStub
 
isShutdown() - Method in class com.google.cloud.spanner.v1.SpannerClient
 
isShutdown() - Method in class com.google.cloud.spanner.v1.stub.GrpcSpannerStub
 
IsSslHandshakeException - Class in com.google.cloud.spanner
 
IsSslHandshakeException() - Constructor for class com.google.cloud.spanner.IsSslHandshakeException
 
isSuccessful() - Method in class com.google.cloud.spanner.Operation
Returns true if the operation completed sucessfully.
isTerminated() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
 
isTerminated() - Method in class com.google.cloud.spanner.admin.database.v1.stub.GrpcDatabaseAdminStub
 
isTerminated() - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminClient
 
isTerminated() - Method in class com.google.cloud.spanner.admin.instance.v1.stub.GrpcInstanceAdminStub
 
isTerminated() - Method in class com.google.cloud.spanner.v1.SpannerClient
 
isTerminated() - Method in class com.google.cloud.spanner.v1.stub.GrpcSpannerStub
 
isTrackTransactionStarter() - Method in class com.google.cloud.spanner.SpannerOptions
 
isTransactionStarted() - Method in interface com.google.cloud.spanner.connection.Connection
 
isUpdateStatement(String) - Method in class com.google.cloud.spanner.connection.StatementParser
Checks whether the given statement is (probably) an update statement.
isUsingEmulator() - Static method in class com.google.cloud.spanner.testing.EmulatorSpannerHelper
Checks whether the emulator is being used.

K

Key - Class in com.google.cloud.spanner
Represents a row key in a Cloud Spanner table or index.
Key.Builder - Class in com.google.cloud.spanner
Builder for Key instances.
KeyRange - Class in com.google.cloud.spanner
Represents a range of rows in a table or index.
KeyRange.Builder - Class in com.google.cloud.spanner
Builder for KeyRange instances.
KeyRange.Endpoint - Enum in com.google.cloud.spanner
Defines whether a range includes or excludes its endpoint keys.
KeySet - Class in com.google.cloud.spanner
Defines a collection of Cloud Spanner keys and/or key ranges.
KeySet.Builder - Class in com.google.cloud.spanner
Builder for KeySet instances.

L

LazySpannerInitializer - Class in com.google.cloud.spanner
Default implementation of AbstractLazyInitializer for a Spanner instance.
LazySpannerInitializer() - Constructor for class com.google.cloud.spanner.LazySpannerInitializer
 
LENIENT_PROPERTY_NAME - Static variable in class com.google.cloud.spanner.connection.ConnectionOptions
Name of the 'lenientMode' connection property.
limit(long) - Static method in class com.google.cloud.spanner.Options
Specifying this will cause the read to yield at most this many rows.
listBackupOperations(InstanceName) - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Lists the backup [long-running operations][google.longrunning.Operation] in the given instance.
listBackupOperations(String) - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Lists the backup [long-running operations][google.longrunning.Operation] in the given instance.
listBackupOperations(ListBackupOperationsRequest) - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Lists the backup [long-running operations][google.longrunning.Operation] in the given instance.
listBackupOperations() - Method in class com.google.cloud.spanner.Backup
Returns all long-running backup operations for this Backup.
listBackupOperations(String, Options.ListOption...) - Method in interface com.google.cloud.spanner.DatabaseAdminClient
Lists long-running backup operations on the specified instance.
listBackupOperations(Options.ListOption...) - Method in class com.google.cloud.spanner.Instance
Returns the long-running backup operations on this instance.
listBackupOperations(String, int, String, String) - Method in class com.google.cloud.spanner.spi.v1.GapicSpannerRpc
 
listBackupOperations(String, int, String, String) - Method in interface com.google.cloud.spanner.spi.v1.SpannerRpc
List all long-running backup operations on the given instance.
listBackupOperationsCallable() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Lists the backup [long-running operations][google.longrunning.Operation] in the given instance.
listBackupOperationsCallable() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStub
 
listBackupOperationsCallable() - Method in class com.google.cloud.spanner.admin.database.v1.stub.GrpcDatabaseAdminStub
 
listBackupOperationsPagedCallable() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Lists the backup [long-running operations][google.longrunning.Operation] in the given instance.
listBackupOperationsPagedCallable() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStub
 
listBackupOperationsPagedCallable() - Method in class com.google.cloud.spanner.admin.database.v1.stub.GrpcDatabaseAdminStub
 
listBackupOperationsSettings() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminSettings.Builder
Returns the builder for the settings used for calls to listBackupOperations.
listBackupOperationsSettings() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminSettings
Returns the object with the settings used for calls to listBackupOperations.
listBackupOperationsSettings() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStubSettings.Builder
Returns the builder for the settings used for calls to listBackupOperations.
listBackupOperationsSettings() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStubSettings
Returns the object with the settings used for calls to listBackupOperations.
listBackups(InstanceName) - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Lists completed and pending backups.
listBackups(String) - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Lists completed and pending backups.
listBackups(ListBackupsRequest) - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Lists completed and pending backups.
listBackups(String, Options.ListOption...) - Method in interface com.google.cloud.spanner.DatabaseAdminClient
Returns the list of Cloud Spanner backups in the given instance.
listBackups(Options.ListOption...) - Method in class com.google.cloud.spanner.Instance
Returns the backups belonging to this instance.
listBackups(String, int, String, String) - Method in class com.google.cloud.spanner.spi.v1.GapicSpannerRpc
 
listBackups(String, int, String, String) - Method in interface com.google.cloud.spanner.spi.v1.SpannerRpc
Lists the backups in the specified instance.
listBackupsCallable() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Lists completed and pending backups.
listBackupsCallable() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStub
 
listBackupsCallable() - Method in class com.google.cloud.spanner.admin.database.v1.stub.GrpcDatabaseAdminStub
 
listBackupsPagedCallable() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Lists completed and pending backups.
listBackupsPagedCallable() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStub
 
listBackupsPagedCallable() - Method in class com.google.cloud.spanner.admin.database.v1.stub.GrpcDatabaseAdminStub
 
listBackupsSettings() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminSettings.Builder
Returns the builder for the settings used for calls to listBackups.
listBackupsSettings() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminSettings
Returns the object with the settings used for calls to listBackups.
listBackupsSettings() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStubSettings.Builder
Returns the builder for the settings used for calls to listBackups.
listBackupsSettings() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStubSettings
Returns the object with the settings used for calls to listBackups.
listDatabaseOperations(InstanceName) - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Lists database [longrunning-operations][google.longrunning.Operation].
listDatabaseOperations(String) - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Lists database [longrunning-operations][google.longrunning.Operation].
listDatabaseOperations(ListDatabaseOperationsRequest) - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Lists database [longrunning-operations][google.longrunning.Operation].
listDatabaseOperations() - Method in class com.google.cloud.spanner.Database
Returns the long-running operations for this database.
listDatabaseOperations(String, Options.ListOption...) - Method in interface com.google.cloud.spanner.DatabaseAdminClient
Lists long-running database operations on the specified instance.
listDatabaseOperations(Options.ListOption...) - Method in class com.google.cloud.spanner.Instance
Returns the long-running database operations on this instance.
listDatabaseOperations(String, int, String, String) - Method in class com.google.cloud.spanner.spi.v1.GapicSpannerRpc
 
listDatabaseOperations(String, int, String, String) - Method in interface com.google.cloud.spanner.spi.v1.SpannerRpc
 
listDatabaseOperationsCallable() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Lists database [longrunning-operations][google.longrunning.Operation].
listDatabaseOperationsCallable() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStub
 
listDatabaseOperationsCallable() - Method in class com.google.cloud.spanner.admin.database.v1.stub.GrpcDatabaseAdminStub
 
listDatabaseOperationsPagedCallable() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Lists database [longrunning-operations][google.longrunning.Operation].
listDatabaseOperationsPagedCallable() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStub
 
listDatabaseOperationsPagedCallable() - Method in class com.google.cloud.spanner.admin.database.v1.stub.GrpcDatabaseAdminStub
 
listDatabaseOperationsSettings() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminSettings.Builder
Returns the builder for the settings used for calls to listDatabaseOperations.
listDatabaseOperationsSettings() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminSettings
Returns the object with the settings used for calls to listDatabaseOperations.
listDatabaseOperationsSettings() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStubSettings.Builder
Returns the builder for the settings used for calls to listDatabaseOperations.
listDatabaseOperationsSettings() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStubSettings
Returns the object with the settings used for calls to listDatabaseOperations.
listDatabases(InstanceName) - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Lists Cloud Spanner databases.
listDatabases(String) - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Lists Cloud Spanner databases.
listDatabases(ListDatabasesRequest) - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Lists Cloud Spanner databases.
listDatabases(String, Options.ListOption...) - Method in interface com.google.cloud.spanner.DatabaseAdminClient
Returns the list of Cloud Spanner database in the given instance.
listDatabases(Options.ListOption...) - Method in class com.google.cloud.spanner.Instance
 
listDatabases(String, int, String) - Method in class com.google.cloud.spanner.spi.v1.GapicSpannerRpc
 
listDatabases(String, int, String) - Method in interface com.google.cloud.spanner.spi.v1.SpannerRpc
 
listDatabasesCallable() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Lists Cloud Spanner databases.
listDatabasesCallable() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStub
 
listDatabasesCallable() - Method in class com.google.cloud.spanner.admin.database.v1.stub.GrpcDatabaseAdminStub
 
listDatabasesPagedCallable() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Lists Cloud Spanner databases.
listDatabasesPagedCallable() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStub
 
listDatabasesPagedCallable() - Method in class com.google.cloud.spanner.admin.database.v1.stub.GrpcDatabaseAdminStub
 
listDatabasesSettings() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminSettings.Builder
Returns the builder for the settings used for calls to listDatabases.
listDatabasesSettings() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminSettings
Returns the object with the settings used for calls to listDatabases.
listDatabasesSettings() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStubSettings.Builder
Returns the builder for the settings used for calls to listDatabases.
listDatabasesSettings() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStubSettings
Returns the object with the settings used for calls to listDatabases.
listInstanceConfigs(ProjectName) - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminClient
Lists the supported instance configurations for a given project.
listInstanceConfigs(String) - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminClient
Lists the supported instance configurations for a given project.
listInstanceConfigs(ListInstanceConfigsRequest) - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminClient
Lists the supported instance configurations for a given project.
listInstanceConfigs(Options.ListOption...) - Method in interface com.google.cloud.spanner.InstanceAdminClient
Lists the supported instance configs for current project.
listInstanceConfigs(int, String) - Method in class com.google.cloud.spanner.spi.v1.GapicSpannerRpc
 
listInstanceConfigs(int, String) - Method in interface com.google.cloud.spanner.spi.v1.SpannerRpc
 
listInstanceConfigsCallable() - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminClient
Lists the supported instance configurations for a given project.
listInstanceConfigsCallable() - Method in class com.google.cloud.spanner.admin.instance.v1.stub.GrpcInstanceAdminStub
 
listInstanceConfigsCallable() - Method in class com.google.cloud.spanner.admin.instance.v1.stub.InstanceAdminStub
 
listInstanceConfigsPagedCallable() - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminClient
Lists the supported instance configurations for a given project.
listInstanceConfigsPagedCallable() - Method in class com.google.cloud.spanner.admin.instance.v1.stub.GrpcInstanceAdminStub
 
listInstanceConfigsPagedCallable() - Method in class com.google.cloud.spanner.admin.instance.v1.stub.InstanceAdminStub
 
listInstanceConfigsSettings() - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminSettings.Builder
Returns the builder for the settings used for calls to listInstanceConfigs.
listInstanceConfigsSettings() - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminSettings
Returns the object with the settings used for calls to listInstanceConfigs.
listInstanceConfigsSettings() - Method in class com.google.cloud.spanner.admin.instance.v1.stub.InstanceAdminStubSettings.Builder
Returns the builder for the settings used for calls to listInstanceConfigs.
listInstanceConfigsSettings() - Method in class com.google.cloud.spanner.admin.instance.v1.stub.InstanceAdminStubSettings
Returns the object with the settings used for calls to listInstanceConfigs.
listInstances(ProjectName) - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminClient
Lists all instances in the given project.
listInstances(String) - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminClient
Lists all instances in the given project.
listInstances(ListInstancesRequest) - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminClient
Lists all instances in the given project.
listInstances(Options.ListOption...) - Method in interface com.google.cloud.spanner.InstanceAdminClient
Lists the instances.
listInstances(int, String, String) - Method in class com.google.cloud.spanner.spi.v1.GapicSpannerRpc
 
listInstances(int, String, String) - Method in interface com.google.cloud.spanner.spi.v1.SpannerRpc
 
listInstancesCallable() - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminClient
Lists all instances in the given project.
listInstancesCallable() - Method in class com.google.cloud.spanner.admin.instance.v1.stub.GrpcInstanceAdminStub
 
listInstancesCallable() - Method in class com.google.cloud.spanner.admin.instance.v1.stub.InstanceAdminStub
 
listInstancesPagedCallable() - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminClient
Lists all instances in the given project.
listInstancesPagedCallable() - Method in class com.google.cloud.spanner.admin.instance.v1.stub.GrpcInstanceAdminStub
 
listInstancesPagedCallable() - Method in class com.google.cloud.spanner.admin.instance.v1.stub.InstanceAdminStub
 
listInstancesSettings() - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminSettings.Builder
Returns the builder for the settings used for calls to listInstances.
listInstancesSettings() - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminSettings
Returns the object with the settings used for calls to listInstances.
listInstancesSettings() - Method in class com.google.cloud.spanner.admin.instance.v1.stub.InstanceAdminStubSettings.Builder
Returns the builder for the settings used for calls to listInstances.
listInstancesSettings() - Method in class com.google.cloud.spanner.admin.instance.v1.stub.InstanceAdminStubSettings
Returns the object with the settings used for calls to listInstances.
listSessions(DatabaseName) - Method in class com.google.cloud.spanner.v1.SpannerClient
Lists all sessions in a given database.
listSessions(String) - Method in class com.google.cloud.spanner.v1.SpannerClient
Lists all sessions in a given database.
listSessions(ListSessionsRequest) - Method in class com.google.cloud.spanner.v1.SpannerClient
Lists all sessions in a given database.
listSessionsCallable() - Method in class com.google.cloud.spanner.v1.SpannerClient
Lists all sessions in a given database.
listSessionsCallable() - Method in class com.google.cloud.spanner.v1.stub.GrpcSpannerStub
 
listSessionsCallable() - Method in class com.google.cloud.spanner.v1.stub.SpannerStub
 
listSessionsPagedCallable() - Method in class com.google.cloud.spanner.v1.SpannerClient
Lists all sessions in a given database.
listSessionsPagedCallable() - Method in class com.google.cloud.spanner.v1.stub.GrpcSpannerStub
 
listSessionsPagedCallable() - Method in class com.google.cloud.spanner.v1.stub.SpannerStub
 
listSessionsSettings() - Method in class com.google.cloud.spanner.v1.SpannerSettings.Builder
Returns the builder for the settings used for calls to listSessions.
listSessionsSettings() - Method in class com.google.cloud.spanner.v1.SpannerSettings
Returns the object with the settings used for calls to listSessions.
listSessionsSettings() - Method in class com.google.cloud.spanner.v1.stub.SpannerStubSettings.Builder
Returns the builder for the settings used for calls to listSessions.
listSessionsSettings() - Method in class com.google.cloud.spanner.v1.stub.SpannerStubSettings
Returns the object with the settings used for calls to listSessions.

M

Mutation - Class in com.google.cloud.spanner
Represents an individual table modification to be applied to Cloud Spanner.
Mutation.Op - Enum in com.google.cloud.spanner
Enumerates the types of mutation that can be applied.
Mutation.WriteBuilder - Class in com.google.cloud.spanner

N

newAbortedDueToConcurrentModificationException(AbortedException) - Static method in class com.google.cloud.spanner.SpannerExceptionFactory
Constructs a specific aborted exception that should only be thrown by a connection after an internal retry aborted due to concurrent modifications.
newAbortedDueToConcurrentModificationException(AbortedException, SpannerException) - Static method in class com.google.cloud.spanner.SpannerExceptionFactory
Constructs a specific aborted exception that should only be thrown by a connection after an internal retry aborted because a database call caused an exception that did not happen during the original attempt.
newAbortedDueToConcurrentModificationException(AbortedDueToConcurrentModificationException) - Static method in class com.google.cloud.spanner.SpannerExceptionFactory
Constructs a new AbortedDueToConcurrentModificationException that can be re-thrown for a transaction that had already been aborted, but that the client application tried to use for additional statements.
newBackupBuilder(BackupId) - Method in interface com.google.cloud.spanner.DatabaseAdminClient
Returns a builder for a Backup object with the given id.
newBuilder() - Static method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminSettings
Returns a new builder for this class.
newBuilder(ClientContext) - Static method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminSettings
Returns a new builder for this class.
newBuilder() - Static method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStubSettings
Returns a new builder for this class.
newBuilder(ClientContext) - Static method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStubSettings
Returns a new builder for this class.
newBuilder() - Static method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminSettings
Returns a new builder for this class.
newBuilder(ClientContext) - Static method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminSettings
Returns a new builder for this class.
newBuilder() - Static method in class com.google.cloud.spanner.admin.instance.v1.stub.InstanceAdminStubSettings
Returns a new builder for this class.
newBuilder(ClientContext) - Static method in class com.google.cloud.spanner.admin.instance.v1.stub.InstanceAdminStubSettings
Returns a new builder for this class.
newBuilder() - Static method in class com.google.cloud.spanner.connection.ConnectionOptions
newBuilder(InstanceId) - Static method in class com.google.cloud.spanner.InstanceInfo
 
newBuilder() - Static method in class com.google.cloud.spanner.Key
Returns a new builder for constructing a key.
newBuilder() - Static method in class com.google.cloud.spanner.KeyRange
Returns a new builder for constructing a range.
newBuilder() - Static method in class com.google.cloud.spanner.KeySet
Returns a new builder that can be used to construct a key set.
newBuilder() - Static method in class com.google.cloud.spanner.PartitionOptions
 
newBuilder() - Static method in class com.google.cloud.spanner.SessionPoolOptions
 
newBuilder() - Static method in class com.google.cloud.spanner.SpannerOptions
 
newBuilder(String) - Static method in class com.google.cloud.spanner.Statement
Creates a new statement builder with the SQL text sql.
newBuilder() - Static method in class com.google.cloud.spanner.Struct
Returns a builder for creating a non-NULL Struct instance.
newBuilder() - Static method in class com.google.cloud.spanner.v1.SpannerSettings
Returns a new builder for this class.
newBuilder(ClientContext) - Static method in class com.google.cloud.spanner.v1.SpannerSettings
Returns a new builder for this class.
newBuilder() - Static method in class com.google.cloud.spanner.v1.stub.SpannerStubSettings
Returns a new builder for this class.
newBuilder(ClientContext) - Static method in class com.google.cloud.spanner.v1.stub.SpannerStubSettings
Returns a new builder for this class.
newInsertBuilder(String) - Static method in class com.google.cloud.spanner.Mutation
Returns a builder that can be used to construct an Mutation.Op.INSERT mutation against table; see the INSERT documentation for mutation semantics.
newInsertOrUpdateBuilder(String) - Static method in class com.google.cloud.spanner.Mutation
Returns a builder that can be used to construct an Mutation.Op.INSERT_OR_UPDATE mutation against table; see the INSERT_OR_UPDATE documentation for mutation semantics.
newInstanceBuilder(InstanceId) - Method in interface com.google.cloud.spanner.InstanceAdminClient
Returns a builder for Instance object with the given id.
newReplaceBuilder(String) - Static method in class com.google.cloud.spanner.Mutation
Returns a builder that can be used to construct an Mutation.Op.REPLACE mutation against table; see the REPLACE documentation for mutation semantics.
newSpannerBatchUpdateException(ErrorCode, String, long[]) - Static method in class com.google.cloud.spanner.SpannerExceptionFactory
 
newSpannerException(ErrorCode, String) - Static method in class com.google.cloud.spanner.SpannerExceptionFactory
 
newSpannerException(ErrorCode, String, Throwable) - Static method in class com.google.cloud.spanner.SpannerExceptionFactory
 
newSpannerException(Throwable) - Static method in class com.google.cloud.spanner.SpannerExceptionFactory
Creates a new exception based on cause.
newSpannerException(Context, Throwable) - Static method in class com.google.cloud.spanner.SpannerExceptionFactory
Creates a new exception based on cause.
newUpdateBuilder(String) - Static method in class com.google.cloud.spanner.Mutation
Returns a builder that can be used to construct an Mutation.Op.UPDATE mutation against table; see the UPDATE documentation for mutation semantics.
next() - Method in class com.google.cloud.spanner.ForwardingResultSet
 
next() - Method in interface com.google.cloud.spanner.ResultSet
Advances the result set to the next row, returning false if no such row exists.
NUM_CHANNELS_PROPERTY_NAME - Static variable in class com.google.cloud.spanner.connection.ConnectionOptions
Name of the 'numChannels' connection property.
numeric() - Static method in class com.google.cloud.spanner.Type
Returns the descriptor for the NUMERIC type.
numeric(BigDecimal) - Static method in class com.google.cloud.spanner.Value
Returns a NUMERIC value.
numericArray(Iterable<BigDecimal>) - Static method in class com.google.cloud.spanner.Value
Returns an ARRAY<NUMERIC> value.

O

OAUTH_TOKEN_PROPERTY_NAME - Static variable in class com.google.cloud.spanner.connection.ConnectionOptions
OAuth token to use for authentication.
of(String, String, String) - Static method in class com.google.cloud.spanner.BackupId
Creates a BackupId given project, instance and backup IDs.
of(InstanceId, String) - Static method in class com.google.cloud.spanner.BackupId
Creates a BackupId given the instance identity and backup id.
of(String) - Static method in class com.google.cloud.spanner.DatabaseId
Creates a DatabaseId from the name of the database.
of(String, String, String) - Static method in class com.google.cloud.spanner.DatabaseId
Creates a DatabaseId given project, instance and database IDs.
of(InstanceId, String) - Static method in class com.google.cloud.spanner.DatabaseId
Creates a DatabaseId given the instance identity and database id.
of(String, String) - Static method in class com.google.cloud.spanner.InstanceConfigId
Creates an InstanceConfigId given project and instance config IDs.
of(String, String) - Static method in class com.google.cloud.spanner.InstanceId
Creates an InstanceId given project and instance IDs.
of(Object...) - Static method in class com.google.cloud.spanner.Key
Construct a key with parts specified by values.
of(String) - Static method in class com.google.cloud.spanner.Statement
Creates a Statement with the given SQL text sql.
of(String, Type) - Static method in class com.google.cloud.spanner.Type.StructField
 
ofExactStaleness(long, TimeUnit) - Static method in class com.google.cloud.spanner.TimestampBound
Returns a timestamp bound that will perform reads and queries at an exact staleness.
ofMaxStaleness(long, TimeUnit) - Static method in class com.google.cloud.spanner.TimestampBound
Returns a timestamp bound that will perform reads and queries at a timestamp chosen to be at most num units stale.
ofMinReadTimestamp(Timestamp) - Static method in class com.google.cloud.spanner.TimestampBound
Returns a timestamp bound that will perform reads and queries at a timestamp chosen to be at least timestamp.
ofReadTimestamp(Timestamp) - Static method in class com.google.cloud.spanner.TimestampBound
Returns a timestamp bound that will perform reads and queries at the given timestamp.
onCompleted() - Method in interface com.google.cloud.spanner.spi.v1.SpannerRpc.ResultStreamConsumer
 
onError(SpannerException) - Method in interface com.google.cloud.spanner.spi.v1.SpannerRpc.ResultStreamConsumer
 
onPartialResultSet(PartialResultSet) - Method in interface com.google.cloud.spanner.spi.v1.SpannerRpc.ResultStreamConsumer
 
openClosed(Key, Key) - Static method in class com.google.cloud.spanner.KeyRange
Returns a key range from start exclusive to end inclusive.
openOpen(Key, Key) - Static method in class com.google.cloud.spanner.KeyRange
Returns a key range from start exclusive to end exclusive.
Operation<R,M> - Class in com.google.cloud.spanner
Represents a long running operation.
Options - Class in com.google.cloud.spanner
Specifies options for various spanner operations
Options.ListOption - Interface in com.google.cloud.spanner
Marker interface to mark options applicable to list operations in admin API.
Options.QueryOption - Interface in com.google.cloud.spanner
Marker interface to mark options applicable to query operation.
Options.ReadAndQueryOption - Interface in com.google.cloud.spanner
Marker interface to mark options applicable to both Read and Query operations
Options.ReadOption - Interface in com.google.cloud.spanner
Marker interface to mark options applicable to read operation
Options.ReadQueryUpdateTransactionOption - Interface in com.google.cloud.spanner
Marker interface to mark options applicable to Read, Query, Update and Write operations
Options.TransactionOption - Interface in com.google.cloud.spanner
Marker interface to mark options applicable to write operations
Options.UpdateOption - Interface in com.google.cloud.spanner
Marker interface to mark options applicable to update operation.

P

pageSize(int) - Static method in class com.google.cloud.spanner.Options
Specifying this will cause the list operations to fetch at most this many records in a page.
pageToken(String) - Static method in class com.google.cloud.spanner.Options
Specifying this will cause the list operation to start fetching the record from this onwards.
Paginated(Iterable<T>, String) - Constructor for class com.google.cloud.spanner.spi.v1.SpannerRpc.Paginated
Creates a new page of results.
parseRfc3339(String) - Static method in class com.google.cloud.spanner.connection.ReadOnlyStalenessUtil
Parses an RFC3339 date/time value with nanosecond precision and returns this as a Timestamp.
Partition - Class in com.google.cloud.spanner
Defines the segments of data to be read in a batch read/query context.
PartitionedDmlTransaction - Class in com.google.cloud.spanner
 
PartitionOptions - Class in com.google.cloud.spanner
PartitionOptions.Builder - Class in com.google.cloud.spanner
Builder for PartitionOptions instance.
partitionQuery(PartitionOptions, Statement, Options.QueryOption...) - Method in interface com.google.cloud.spanner.BatchReadOnlyTransaction
Returns a list of Partition to execute a query against the database.
partitionQuery(PartitionQueryRequest, Map<SpannerRpc.Option, ?>) - Method in class com.google.cloud.spanner.spi.v1.GapicSpannerRpc
 
partitionQuery(PartitionQueryRequest, Map<SpannerRpc.Option, ?>) - Method in interface com.google.cloud.spanner.spi.v1.SpannerRpc
 
partitionQuery(PartitionQueryRequest) - Method in class com.google.cloud.spanner.v1.SpannerClient
Creates a set of partition tokens that can be used to execute a query operation in parallel.
partitionQueryCallable() - Method in class com.google.cloud.spanner.v1.SpannerClient
Creates a set of partition tokens that can be used to execute a query operation in parallel.
partitionQueryCallable() - Method in class com.google.cloud.spanner.v1.stub.GrpcSpannerStub
 
partitionQueryCallable() - Method in class com.google.cloud.spanner.v1.stub.SpannerStub
 
partitionQuerySettings() - Method in class com.google.cloud.spanner.v1.SpannerSettings.Builder
Returns the builder for the settings used for calls to partitionQuery.
partitionQuerySettings() - Method in class com.google.cloud.spanner.v1.SpannerSettings
Returns the object with the settings used for calls to partitionQuery.
partitionQuerySettings() - Method in class com.google.cloud.spanner.v1.stub.SpannerStubSettings.Builder
Returns the builder for the settings used for calls to partitionQuery.
partitionQuerySettings() - Method in class com.google.cloud.spanner.v1.stub.SpannerStubSettings
Returns the object with the settings used for calls to partitionQuery.
partitionRead(PartitionOptions, String, KeySet, Iterable<String>, Options.ReadOption...) - Method in interface com.google.cloud.spanner.BatchReadOnlyTransaction
Returns a list of Partition to read zero or more rows from a database.
partitionRead(PartitionReadRequest, Map<SpannerRpc.Option, ?>) - Method in class com.google.cloud.spanner.spi.v1.GapicSpannerRpc
 
partitionRead(PartitionReadRequest, Map<SpannerRpc.Option, ?>) - Method in interface com.google.cloud.spanner.spi.v1.SpannerRpc
 
partitionRead(PartitionReadRequest) - Method in class com.google.cloud.spanner.v1.SpannerClient
Creates a set of partition tokens that can be used to execute a read operation in parallel.
partitionReadCallable() - Method in class com.google.cloud.spanner.v1.SpannerClient
Creates a set of partition tokens that can be used to execute a read operation in parallel.
partitionReadCallable() - Method in class com.google.cloud.spanner.v1.stub.GrpcSpannerStub
 
partitionReadCallable() - Method in class com.google.cloud.spanner.v1.stub.SpannerStub
 
partitionReadSettings() - Method in class com.google.cloud.spanner.v1.SpannerSettings.Builder
Returns the builder for the settings used for calls to partitionRead.
partitionReadSettings() - Method in class com.google.cloud.spanner.v1.SpannerSettings
Returns the object with the settings used for calls to partitionRead.
partitionReadSettings() - Method in class com.google.cloud.spanner.v1.stub.SpannerStubSettings.Builder
Returns the builder for the settings used for calls to partitionRead.
partitionReadSettings() - Method in class com.google.cloud.spanner.v1.stub.SpannerStubSettings
Returns the object with the settings used for calls to partitionRead.
partitionReadUsingIndex(PartitionOptions, String, String, KeySet, Iterable<String>, Options.ReadOption...) - Method in interface com.google.cloud.spanner.BatchReadOnlyTransaction
Returns a list of Partition to read zero or more rows from a database using an index.
prefetchChunks(int) - Static method in class com.google.cloud.spanner.Options
Specifying this will allow the client to prefetch up to prefetchChunks PartialResultSet chunks for read and query.
prefix(Key) - Static method in class com.google.cloud.spanner.KeyRange
Returns a key range that covers all keys where the first prefix.size() components match prefix exactly.
prefixRange(Key) - Static method in class com.google.cloud.spanner.KeySet
Creates a key set that covers all keys where the first prefix.size() components match prefix exactly.
prepareReadWriteTransaction() - Method in interface com.google.cloud.spanner.Session
Prepares a transaction for use by a subsequent #readWriteTransaction() or DatabaseClient.write(Iterable) call.
propagateInterrupt(InterruptedException) - Static method in class com.google.cloud.spanner.SpannerExceptionFactory
 
propagateTimeout(TimeoutException) - Static method in class com.google.cloud.spanner.SpannerExceptionFactory
Transforms a TimeoutException to a SpannerException.
putAllLabels(Map<String, String>) - Method in class com.google.cloud.spanner.Instance.Builder
 
putAllLabels(Map<String, String>) - Method in class com.google.cloud.spanner.InstanceInfo.Builder
 

R

range(KeyRange) - Static method in class com.google.cloud.spanner.KeySet
Creates a key set containing a single range.
read(String, KeySet, Iterable<String>, Options.ReadOption...) - Method in interface com.google.cloud.spanner.ReadContext
Reads zero or more rows from a database.
read(ReadRequest, SpannerRpc.ResultStreamConsumer, Map<SpannerRpc.Option, ?>) - Method in class com.google.cloud.spanner.spi.v1.GapicSpannerRpc
 
read(ReadRequest, SpannerRpc.ResultStreamConsumer, Map<SpannerRpc.Option, ?>) - Method in interface com.google.cloud.spanner.spi.v1.SpannerRpc
 
read(ReadRequest) - Method in class com.google.cloud.spanner.v1.SpannerClient
Reads rows from the database using key lookups and scans, as a simple key/value style alternative to [ExecuteSql][google.spanner.v1.Spanner.ExecuteSql].
readAsync(String, KeySet, Iterable<String>, Options.ReadOption...) - Method in interface com.google.cloud.spanner.ReadContext
Same as #read(String, KeySet, Iterable, ReadOption...), but is guaranteed to be non-blocking and will return the results as an AsyncResultSet.
readCallable() - Method in class com.google.cloud.spanner.v1.SpannerClient
Reads rows from the database using key lookups and scans, as a simple key/value style alternative to [ExecuteSql][google.spanner.v1.Spanner.ExecuteSql].
readCallable() - Method in class com.google.cloud.spanner.v1.stub.GrpcSpannerStub
 
readCallable() - Method in class com.google.cloud.spanner.v1.stub.SpannerStub
 
ReadContext - Interface in com.google.cloud.spanner
A concurrency context in which to run a read or SQL statement.
ReadContext.QueryAnalyzeMode - Enum in com.google.cloud.spanner
Used to specify the mode in which the query should be analyzed by ReadContext.analyzeQuery(Statement,QueryAnalyzeMode).
READONLY_PROPERTY_NAME - Static variable in class com.google.cloud.spanner.connection.ConnectionOptions
Name of the 'readonly' connection property.
ReadOnlyStalenessUtil - Class in com.google.cloud.spanner.connection
Util class for parsing and converting ReadOnlyStaleness values to/from strings.
ReadOnlyStalenessUtil() - Constructor for class com.google.cloud.spanner.connection.ReadOnlyStalenessUtil
 
readOnlyTransaction() - Method in interface com.google.cloud.spanner.DatabaseClient
Returns a read-only transaction context in which a multiple reads and/or queries can be performed using TimestampBound.strong() concurrency.
readOnlyTransaction(TimestampBound) - Method in interface com.google.cloud.spanner.DatabaseClient
Returns a read-only transaction context in which a multiple reads and/or queries can be performed at the given timestamp bound.
ReadOnlyTransaction - Interface in com.google.cloud.spanner
A transaction type that provides guaranteed consistency across several reads, but does not allow writes.
readRow(String, Key, Iterable<String>) - Method in interface com.google.cloud.spanner.ReadContext
Reads a single row from a database, returning null if the row does not exist.
readRowAsync(String, Key, Iterable<String>) - Method in interface com.google.cloud.spanner.ReadContext
Same as ReadContext.readRow(String, Key, Iterable), but is guaranteed to be non-blocking.
readRowUsingIndex(String, String, Key, Iterable<String>) - Method in interface com.google.cloud.spanner.ReadContext
Reads a single row from a database using an index, returning null if the row does not exist.
readRowUsingIndexAsync(String, String, Key, Iterable<String>) - Method in interface com.google.cloud.spanner.ReadContext
Same as ReadContext.readRowUsingIndex(String, String, Key, Iterable), but is guaranteed to be non-blocking.
readSettings() - Method in class com.google.cloud.spanner.v1.SpannerSettings.Builder
Returns the builder for the settings used for calls to read.
readSettings() - Method in class com.google.cloud.spanner.v1.SpannerSettings
Returns the object with the settings used for calls to read.
readSettings() - Method in class com.google.cloud.spanner.v1.stub.SpannerStubSettings.Builder
Returns the builder for the settings used for calls to read.
readSettings() - Method in class com.google.cloud.spanner.v1.stub.SpannerStubSettings
Returns the object with the settings used for calls to read.
readUsingIndex(String, String, KeySet, Iterable<String>, Options.ReadOption...) - Method in interface com.google.cloud.spanner.ReadContext
Reads zero or more rows from a database using an index.
readUsingIndexAsync(String, String, KeySet, Iterable<String>, Options.ReadOption...) - Method in interface com.google.cloud.spanner.ReadContext
Same as #readUsingIndex(String, String, KeySet, Iterable, ReadOption...), but is guaranteed to be non-blocking and will return its results as an AsyncResultSet.
readWriteTransaction(Options.TransactionOption...) - Method in interface com.google.cloud.spanner.DatabaseClient
Returns a transaction runner for executing a single logical transaction with retries.
reload() - Method in class com.google.cloud.spanner.Backup
Fetches the backup's current information and returns a new Backup instance.
reload() - Method in class com.google.cloud.spanner.Database
Fetches the database's current information.
reload() - Method in class com.google.cloud.spanner.Instance
 
reload() - Method in class com.google.cloud.spanner.InstanceConfig
Gets the current state of this instance config.
reload() - Method in class com.google.cloud.spanner.Operation
Fetches the current status of this operation.
RemoteSpannerHelper - Class in com.google.cloud.spanner.testing
Utility that provides access to a Cloud Spanner instance to use for tests, and allows uniquely named test databases to be created within that instance.
RemoteSpannerHelper(SpannerOptions, InstanceId, Spanner) - Constructor for class com.google.cloud.spanner.testing.RemoteSpannerHelper
 
removeCommentsAndTrim(String) - Static method in class com.google.cloud.spanner.connection.StatementParser
Removes comments from and trims the given sql statement.
removeTransactionRetryListener(TransactionRetryListener) - Method in interface com.google.cloud.spanner.connection.Connection
Removes one existing TransactionRetryListener from this Connection, if it is present (optional operation).
request(int) - Method in interface com.google.cloud.spanner.spi.v1.SpannerRpc.StreamingCall
Requests more messages from the stream.
resetForRetry() - Method in interface com.google.cloud.spanner.TransactionManager
Creates a new transaction for retry.
resetForRetryAsync() - Method in interface com.google.cloud.spanner.AsyncTransactionManager
Creates a new transaction for retry.
restore(DatabaseId) - Method in class com.google.cloud.spanner.Backup
Restores this backup to the specified database.
restoreDatabase(String, String, String, String) - Method in interface com.google.cloud.spanner.DatabaseAdminClient
Restore a database from a backup.
restoreDatabase(String, String, String) - Method in class com.google.cloud.spanner.spi.v1.GapicSpannerRpc
 
restoreDatabase(String, String, String) - Method in interface com.google.cloud.spanner.spi.v1.SpannerRpc
Restore a backup into the given database.
restoreDatabaseAsync(InstanceName, String, BackupName) - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Create a new database by restoring from a completed backup.
restoreDatabaseAsync(InstanceName, String, String) - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Create a new database by restoring from a completed backup.
restoreDatabaseAsync(String, String, BackupName) - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Create a new database by restoring from a completed backup.
restoreDatabaseAsync(String, String, String) - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Create a new database by restoring from a completed backup.
restoreDatabaseAsync(RestoreDatabaseRequest) - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Create a new database by restoring from a completed backup.
restoreDatabaseCallable() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Create a new database by restoring from a completed backup.
restoreDatabaseCallable() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStub
 
restoreDatabaseCallable() - Method in class com.google.cloud.spanner.admin.database.v1.stub.GrpcDatabaseAdminStub
 
restoreDatabaseOperationCallable() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Create a new database by restoring from a completed backup.
restoreDatabaseOperationCallable() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStub
 
restoreDatabaseOperationCallable() - Method in class com.google.cloud.spanner.admin.database.v1.stub.GrpcDatabaseAdminStub
 
restoreDatabaseOperationSettings() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminSettings.Builder
Returns the builder for the settings used for calls to restoreDatabase.
restoreDatabaseOperationSettings() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminSettings
Returns the object with the settings used for calls to restoreDatabase.
restoreDatabaseOperationSettings() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStubSettings.Builder
Returns the builder for the settings used for calls to restoreDatabase.
restoreDatabaseOperationSettings() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStubSettings
Returns the object with the settings used for calls to restoreDatabase.
restoreDatabaseSettings() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminSettings.Builder
Returns the builder for the settings used for calls to restoreDatabase.
restoreDatabaseSettings() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminSettings
Returns the object with the settings used for calls to restoreDatabase.
restoreDatabaseSettings() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStubSettings.Builder
Returns the builder for the settings used for calls to restoreDatabase.
restoreDatabaseSettings() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStubSettings
Returns the object with the settings used for calls to restoreDatabase.
RestoreInfo - Class in com.google.cloud.spanner
Represents the restore information of a Cloud Spanner database.
RestoreInfo.RestoreSourceType - Enum in com.google.cloud.spanner
Source of the restore information.
ResultSet - Interface in com.google.cloud.spanner
Provides access to the data returned by a Cloud Spanner read or query.
ResultSets - Class in com.google.cloud.spanner
Utility methods for working with ResultSet.
resume() - Method in interface com.google.cloud.spanner.AsyncResultSet
Resume callbacks from the cursor.
resume() - Method in class com.google.cloud.spanner.ForwardingAsyncResultSet
 
RETRY_ABORTS_INTERNALLY_PROPERTY_NAME - Static variable in class com.google.cloud.spanner.connection.ConnectionOptions
Name of the 'retry aborts internally' connection property.
retryFinished(Timestamp, long, int, TransactionRetryListener.RetryResult) - Method in interface com.google.cloud.spanner.connection.TransactionRetryListener
This method is called when a retry has finished.
retryStarting(Timestamp, long, int) - Method in interface com.google.cloud.spanner.connection.TransactionRetryListener
This method is called when a retry is about to start.
rollback() - Method in interface com.google.cloud.spanner.connection.Connection
Rollbacks the current transaction of this connection.
rollback(RollbackRequest, Map<SpannerRpc.Option, ?>) - Method in class com.google.cloud.spanner.spi.v1.GapicSpannerRpc
 
rollback(RollbackRequest, Map<SpannerRpc.Option, ?>) - Method in interface com.google.cloud.spanner.spi.v1.SpannerRpc
 
rollback() - Method in interface com.google.cloud.spanner.TransactionManager
Rolls back the currently active transaction.
rollback(SessionName, ByteString) - Method in class com.google.cloud.spanner.v1.SpannerClient
Rolls back a transaction, releasing any locks it holds.
rollback(String, ByteString) - Method in class com.google.cloud.spanner.v1.SpannerClient
Rolls back a transaction, releasing any locks it holds.
rollback(RollbackRequest) - Method in class com.google.cloud.spanner.v1.SpannerClient
Rolls back a transaction, releasing any locks it holds.
rollbackAsync() - Method in interface com.google.cloud.spanner.AsyncTransactionManager
Rolls back the currently active transaction.
rollbackAsync() - Method in interface com.google.cloud.spanner.connection.Connection
Rollbacks the current transaction of this connection.
rollbackAsync(RollbackRequest, Map<SpannerRpc.Option, ?>) - Method in class com.google.cloud.spanner.spi.v1.GapicSpannerRpc
 
rollbackAsync(RollbackRequest, Map<SpannerRpc.Option, ?>) - Method in interface com.google.cloud.spanner.spi.v1.SpannerRpc
 
rollbackCallable() - Method in class com.google.cloud.spanner.v1.SpannerClient
Rolls back a transaction, releasing any locks it holds.
rollbackCallable() - Method in class com.google.cloud.spanner.v1.stub.GrpcSpannerStub
 
rollbackCallable() - Method in class com.google.cloud.spanner.v1.stub.SpannerStub
 
rollbackSettings() - Method in class com.google.cloud.spanner.v1.SpannerSettings.Builder
Returns the builder for the settings used for calls to rollback.
rollbackSettings() - Method in class com.google.cloud.spanner.v1.SpannerSettings
Returns the object with the settings used for calls to rollback.
rollbackSettings() - Method in class com.google.cloud.spanner.v1.stub.SpannerStubSettings.Builder
Returns the builder for the settings used for calls to rollback.
rollbackSettings() - Method in class com.google.cloud.spanner.v1.stub.SpannerStubSettings
Returns the object with the settings used for calls to rollback.
run(TransactionRunner.TransactionCallable<T>) - Method in interface com.google.cloud.spanner.TransactionRunner
Executes a read-write transaction, with retries as necessary.
run(TransactionContext) - Method in interface com.google.cloud.spanner.TransactionRunner.TransactionCallable
Invoked by the library framework to perform a single attempt of a transaction.
runAsync(AsyncRunner.AsyncWork<R>, Executor) - Method in interface com.google.cloud.spanner.AsyncRunner
Executes a read/write transaction asynchronously using the given executor.
runAsync(Options.TransactionOption...) - Method in interface com.google.cloud.spanner.DatabaseClient
Returns an asynchronous transaction runner for executing a single logical transaction with retries.
runBatch() - Method in interface com.google.cloud.spanner.connection.Connection
Sends all buffered DML or DDL statements of the current batch to the database, waits for these to be executed and ends the current batch.
runBatchAsync() - Method in interface com.google.cloud.spanner.connection.Connection
Sends all buffered DML or DDL statements of the current batch to the database, waits for these to be executed and ends the current batch.

S

Session - Interface in com.google.cloud.spanner
A Session can be used to perform transactions that read and/or modify data in a Cloud Spanner database.
SessionNotFoundException - Exception in com.google.cloud.spanner
Exception thrown by Cloud Spanner when an operation detects that the session that is being used is no longer valid.
SessionPoolOptions - Class in com.google.cloud.spanner
Options for the session pool used by DatabaseClient.
SessionPoolOptions.Builder - Class in com.google.cloud.spanner
Builder for creating SessionPoolOptions.
set(String) - Method in class com.google.cloud.spanner.Mutation.WriteBuilder
Returns a binder to set the value of columnName that should be applied by the mutation.
set(String) - Method in class com.google.cloud.spanner.Struct.Builder
Returns a binder to set the value of a new field in the struct named fieldName.
setAll() - Method in class com.google.cloud.spanner.KeySet.Builder
Makes the key set retrieve all rows of a table or index.
setAutocommit(boolean) - Method in interface com.google.cloud.spanner.connection.Connection
Sets autocommit on/off for this Connection.
setAutocommitDmlMode(AutocommitDmlMode) - Method in interface com.google.cloud.spanner.connection.Connection
Sets the mode for executing DML statements in autocommit mode for this connection.
setAutoThrottleAdministrativeRequests() - Method in class com.google.cloud.spanner.SpannerOptions.Builder
Instructs the client library to automatically throttle the number of administrative requests if the rate of administrative requests generated by this Spanner instance will exceed the administrative limits Cloud Spanner.
setBackupIAMPolicy(String, String, Policy) - Method in interface com.google.cloud.spanner.DatabaseAdminClient
Updates the IAM policy for the given backup and returns the resulting policy.
setBlockIfPoolExhausted() - Method in class com.google.cloud.spanner.SessionPoolOptions.Builder
If all sessions are in use and there is no more room for creating new sessions, block for a session to become available.
setCallback(Executor, AsyncResultSet.ReadyCallback) - Method in interface com.google.cloud.spanner.AsyncResultSet
Register a callback with the ResultSet to be made aware when more data is available, changing the usage pattern from sync to async.
setCallback(Executor, AsyncResultSet.ReadyCallback) - Method in class com.google.cloud.spanner.ForwardingAsyncResultSet
 
setCallCredentialsProvider(SpannerOptions.CallCredentialsProvider) - Method in class com.google.cloud.spanner.SpannerOptions.Builder
Sets a SpannerOptions.CallCredentialsProvider that can deliver CallCredentials to use on a per-gRPC basis.
setChannelConfigurator(ApiFunction<ManagedChannelBuilder, ManagedChannelBuilder>) - Method in class com.google.cloud.spanner.SpannerOptions.Builder
Sets an ApiFunction that will be used to configure the transport channel.
setChannelProvider(TransportChannelProvider) - Method in class com.google.cloud.spanner.SpannerOptions.Builder
Sets the ChannelProvider.
setCompressorName(String) - Method in class com.google.cloud.spanner.SpannerOptions.Builder
Sets the compression to use for all gRPC calls.
setCredentialsUrl(String) - Method in class com.google.cloud.spanner.connection.ConnectionOptions.Builder
Sets the URL of the credentials file to use for this connection.
setDatabase(DatabaseId) - Method in class com.google.cloud.spanner.BackupInfo.Builder
Required for creating a new backup.
setDatabaseAdminIAMPolicy(String, Policy) - Method in class com.google.cloud.spanner.spi.v1.GapicSpannerRpc
 
setDatabaseAdminIAMPolicy(String, Policy) - Method in interface com.google.cloud.spanner.spi.v1.SpannerRpc
Updates the IAM policy for the given resource using the DatabaseAdminStub.
setDatabaseIAMPolicy(String, String, Policy) - Method in interface com.google.cloud.spanner.DatabaseAdminClient
Updates the IAM policy for the given database and returns the resulting policy.
setDefaultQueryOptions(DatabaseId, ExecuteSqlRequest.QueryOptions) - Method in class com.google.cloud.spanner.SpannerOptions.Builder
Sets the default ExecuteSqlRequest.QueryOptions that will be used for all queries on the specified database.
setDisplayName(String) - Method in class com.google.cloud.spanner.Instance.Builder
 
setDisplayName(String) - Method in class com.google.cloud.spanner.InstanceInfo.Builder
 
setEmulatorHost(String) - Method in class com.google.cloud.spanner.SpannerOptions.Builder
Sets the host of an emulator to use.
setEnd(Key) - Method in class com.google.cloud.spanner.KeyRange.Builder
Sets the end key of the range.
setEndType(KeyRange.Endpoint) - Method in class com.google.cloud.spanner.KeyRange.Builder
Sets whether the end key is inclusive (CLOSED) or exclusive (OPEN).
setExpireTime(Timestamp) - Method in class com.google.cloud.spanner.BackupInfo.Builder
Required for creating a new backup.
setFailIfPoolExhausted() - Method in class com.google.cloud.spanner.SessionPoolOptions.Builder
If all sessions are in use and and maxSessions has been reached, fail the request by throwing a SpannerException with the error code RESOURCE_EXHAUSTED.
setHost(String) - Method in class com.google.cloud.spanner.SpannerOptions.Builder
 
setIamPolicy(ResourceName, Policy) - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Sets the access control policy on a database or backup resource.
setIamPolicy(String, Policy) - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Sets the access control policy on a database or backup resource.
setIamPolicy(SetIamPolicyRequest) - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Sets the access control policy on a database or backup resource.
setIamPolicy(ResourceName, Policy) - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminClient
Sets the access control policy on an instance resource.
setIamPolicy(String, Policy) - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminClient
Sets the access control policy on an instance resource.
setIamPolicy(SetIamPolicyRequest) - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminClient
Sets the access control policy on an instance resource.
setIAMPolicy(Policy) - Method in class com.google.cloud.spanner.Backup
Updates the IAM policy for this backup and returns the resulting policy.
setIAMPolicy(Policy) - Method in class com.google.cloud.spanner.Database
Updates the IAM policy for this database and returns the resulting policy.
setIAMPolicy(Policy) - Method in class com.google.cloud.spanner.Instance
Updates the IAM policy for this instance and returns the resulting policy.
setIamPolicyCallable() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Sets the access control policy on a database or backup resource.
setIamPolicyCallable() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStub
 
setIamPolicyCallable() - Method in class com.google.cloud.spanner.admin.database.v1.stub.GrpcDatabaseAdminStub
 
setIamPolicyCallable() - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminClient
Sets the access control policy on an instance resource.
setIamPolicyCallable() - Method in class com.google.cloud.spanner.admin.instance.v1.stub.GrpcInstanceAdminStub
 
setIamPolicyCallable() - Method in class com.google.cloud.spanner.admin.instance.v1.stub.InstanceAdminStub
 
setIamPolicySettings() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminSettings.Builder
Returns the builder for the settings used for calls to setIamPolicy.
setIamPolicySettings() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminSettings
Returns the object with the settings used for calls to setIamPolicy.
setIamPolicySettings() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStubSettings.Builder
Returns the builder for the settings used for calls to setIamPolicy.
setIamPolicySettings() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStubSettings
Returns the object with the settings used for calls to setIamPolicy.
setIamPolicySettings() - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminSettings.Builder
Returns the builder for the settings used for calls to setIamPolicy.
setIamPolicySettings() - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminSettings
Returns the object with the settings used for calls to setIamPolicy.
setIamPolicySettings() - Method in class com.google.cloud.spanner.admin.instance.v1.stub.InstanceAdminStubSettings.Builder
Returns the builder for the settings used for calls to setIamPolicy.
setIamPolicySettings() - Method in class com.google.cloud.spanner.admin.instance.v1.stub.InstanceAdminStubSettings
Returns the object with the settings used for calls to setIamPolicy.
setInstanceAdminIAMPolicy(String, Policy) - Method in class com.google.cloud.spanner.spi.v1.GapicSpannerRpc
 
setInstanceAdminIAMPolicy(String, Policy) - Method in interface com.google.cloud.spanner.spi.v1.SpannerRpc
Updates the IAM policy for the given resource using the InstanceAdminStub.
setInstanceConfigId(InstanceConfigId) - Method in class com.google.cloud.spanner.Instance.Builder
 
setInstanceConfigId(InstanceConfigId) - Method in class com.google.cloud.spanner.InstanceInfo.Builder
 
setInstanceIAMPolicy(String, Policy) - Method in interface com.google.cloud.spanner.InstanceAdminClient
Updates the IAM policy for the given instance and returns the resulting policy.
setInterceptorProvider(GrpcInterceptorProvider) - Method in class com.google.cloud.spanner.SpannerOptions.Builder
Sets the GrpcInterceptorProvider.
setKeepAliveIntervalMinutes(int) - Method in class com.google.cloud.spanner.SessionPoolOptions.Builder
How frequently to keep alive idle sessions.
setMaxIdleSessions(int) - Method in class com.google.cloud.spanner.SessionPoolOptions.Builder
Maximum number of idle sessions that this pool will maintain.
setMaxPartitions(long) - Method in class com.google.cloud.spanner.PartitionOptions.Builder
 
setMaxSessions(int) - Method in class com.google.cloud.spanner.SessionPoolOptions.Builder
Maximum number of sessions that this pool will have.
setMinSessions(int) - Method in class com.google.cloud.spanner.SessionPoolOptions.Builder
Minimum number of sessions that this pool will always maintain.
setNodeCount(int) - Method in class com.google.cloud.spanner.Instance.Builder
 
setNodeCount(int) - Method in class com.google.cloud.spanner.InstanceInfo.Builder
 
setNumChannels(int) - Method in class com.google.cloud.spanner.SpannerOptions.Builder
Sets the number of gRPC channels to use.
setOAuthToken(String) - Method in class com.google.cloud.spanner.connection.ConnectionOptions.Builder
Sets the OAuth token to use with this connection.
setOptimizerVersion(String) - Method in interface com.google.cloud.spanner.connection.Connection
Sets the query optimizer version to use for this connection.
setPartitionedDmlTimeout(Duration) - Method in class com.google.cloud.spanner.SpannerOptions.Builder
Sets a timeout specifically for Partitioned DML statements executed through DatabaseClient#executePartitionedUpdate(Statement).
setPartitionSizeBytes(long) - Method in class com.google.cloud.spanner.PartitionOptions.Builder
The desired data size for each partition generated.
setPrefetchChunks(int) - Method in class com.google.cloud.spanner.SpannerOptions.Builder
Specifying this will allow the client to prefetch up to prefetchChunks PartialResultSet chunks for each read and query.
setReadOnly(boolean) - Method in interface com.google.cloud.spanner.connection.Connection
Sets this connection to read-only or read-write.
setReadOnlyStaleness(TimestampBound) - Method in interface com.google.cloud.spanner.connection.Connection
Sets the staleness to use for the current read-only transaction.
setRemoveInactiveSessionAfter(Duration) - Method in class com.google.cloud.spanner.SessionPoolOptions.Builder
 
setRetryAbortsInternally(boolean) - Method in interface com.google.cloud.spanner.connection.Connection
Sets whether this connection will internally retry read/write transactions that abort.
setRetrySettings(RetrySettings) - Method in class com.google.cloud.spanner.SpannerOptions.Builder
SpannerOptions.Builder does not support global retry settings, as it creates three different gRPC clients: Spanner, DatabaseAdminClient and InstanceAdminClient.
setSessionLabels(Map<String, String>) - Method in class com.google.cloud.spanner.SpannerOptions.Builder
Sets the labels to add to all Sessions created in this client.
setSessionPoolOption(SessionPoolOptions) - Method in class com.google.cloud.spanner.SpannerOptions.Builder
Sets the options for managing the session pool.
setSessionPoolOptions(SessionPoolOptions) - Method in class com.google.cloud.spanner.connection.ConnectionOptions.Builder
Sets the SessionPoolOptions to use for the connection.
setSpan(Span) - Method in class com.google.cloud.spanner.PartitionedDmlTransaction
 
setStart(Key) - Method in class com.google.cloud.spanner.KeyRange.Builder
Sets the start key of the range.
setStartType(KeyRange.Endpoint) - Method in class com.google.cloud.spanner.KeyRange.Builder
Sets whether the start key is inclusive (CLOSED) or exclusive (OPEN).
setState(InstanceInfo.State) - Method in class com.google.cloud.spanner.Instance.Builder
 
setState(InstanceInfo.State) - Method in class com.google.cloud.spanner.InstanceInfo.Builder
 
setStatementTimeout(long, TimeUnit) - Method in interface com.google.cloud.spanner.connection.Connection
Sets the duration the connection should wait before automatically aborting the execution of a statement.
setTrackTransactionStarter() - Method in class com.google.cloud.spanner.SpannerOptions.Builder
Instructs the client library to track the first request of each read/write transaction.
setTransactionMode(TransactionMode) - Method in interface com.google.cloud.spanner.connection.Connection
Sets the transaction mode to use for current transaction.
setTransportOptions(TransportOptions) - Method in class com.google.cloud.spanner.SpannerOptions.Builder
 
setUri(String) - Method in class com.google.cloud.spanner.connection.ConnectionOptions.Builder
Sets the URI of the Cloud Spanner database to connect to.
setWriteSessionsFraction(float) - Method in class com.google.cloud.spanner.SessionPoolOptions.Builder
Deprecated.
This configuration value is no longer in use. The session pool does not prepare any sessions for read/write transactions. Instead, a transaction will automatically be started by the first statement that is executed by a transaction by including a BeginTransaction option with that statement.

This method may be removed in a future release.

shouldRefreshRpc(ServiceRpc) - Method in class com.google.cloud.spanner.SpannerOptions
 
shouldRefreshService(Spanner) - Method in class com.google.cloud.spanner.SpannerOptions
 
shutdown() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
 
shutdown() - Method in class com.google.cloud.spanner.admin.database.v1.stub.GrpcDatabaseAdminStub
 
shutdown() - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminClient
 
shutdown() - Method in class com.google.cloud.spanner.admin.instance.v1.stub.GrpcInstanceAdminStub
 
shutdown() - Method in class com.google.cloud.spanner.spi.v1.GapicSpannerRpc
 
shutdown() - Method in interface com.google.cloud.spanner.spi.v1.SpannerRpc
 
shutdown() - Method in class com.google.cloud.spanner.v1.SpannerClient
 
shutdown() - Method in class com.google.cloud.spanner.v1.stub.GrpcSpannerStub
 
shutdownNow() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
 
shutdownNow() - Method in class com.google.cloud.spanner.admin.database.v1.stub.GrpcDatabaseAdminStub
 
shutdownNow() - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminClient
 
shutdownNow() - Method in class com.google.cloud.spanner.admin.instance.v1.stub.GrpcInstanceAdminStub
 
shutdownNow() - Method in class com.google.cloud.spanner.v1.SpannerClient
 
shutdownNow() - Method in class com.google.cloud.spanner.v1.stub.GrpcSpannerStub
 
singleKey(Key) - Static method in class com.google.cloud.spanner.KeySet
Creates a key set containing a single key.
singleUse() - Method in interface com.google.cloud.spanner.DatabaseClient
Returns a context in which a single read can be performed using TimestampBound.strong() concurrency.
singleUse(TimestampBound) - Method in interface com.google.cloud.spanner.DatabaseClient
Returns a context in which a single read can be performed at the given timestamp bound.
singleUseReadOnlyTransaction() - Method in interface com.google.cloud.spanner.DatabaseClient
Returns a read-only transaction context in which a single read or query can be performed using TimestampBound.strong() concurrency.
singleUseReadOnlyTransaction(TimestampBound) - Method in interface com.google.cloud.spanner.DatabaseClient
Returns a read-only transaction context in which a single read or query can be performed at given timestamp bound.
size() - Method in class com.google.cloud.spanner.Key
Returns the number of parts in this key, including null values.
Spanner - Interface in com.google.cloud.spanner
An interface for Cloud Spanner.
SPANNER_EMULATOR_HOST - Static variable in class com.google.cloud.spanner.testing.EmulatorSpannerHelper
 
SPANNER_URI_FORMAT - Static variable in class com.google.cloud.spanner.connection.ConnectionOptions.Builder
Spanner ConnectionOptions URI format.
SpannerApiFutures - Class in com.google.cloud.spanner
 
SpannerApiFutures() - Constructor for class com.google.cloud.spanner.SpannerApiFutures
 
SpannerBatchUpdateException - Exception in com.google.cloud.spanner
 
SpannerClient - Class in com.google.cloud.spanner.v1
Service Description: Cloud Spanner API
SpannerClient(SpannerSettings) - Constructor for class com.google.cloud.spanner.v1.SpannerClient
Constructs an instance of SpannerClient, using the given settings.
SpannerClient(SpannerStub) - Constructor for class com.google.cloud.spanner.v1.SpannerClient
 
SpannerClient.ListSessionsFixedSizeCollection - Class in com.google.cloud.spanner.v1
 
SpannerClient.ListSessionsPage - Class in com.google.cloud.spanner.v1
 
SpannerClient.ListSessionsPagedResponse - Class in com.google.cloud.spanner.v1
 
SpannerErrorInterceptor - Class in com.google.cloud.spanner.spi.v1
Adds error details to statuses returned by the Cloud Spanner API.
SpannerErrorInterceptor() - Constructor for class com.google.cloud.spanner.spi.v1.SpannerErrorInterceptor
 
SpannerException - Exception in com.google.cloud.spanner
Base exception type for all exceptions produced by the Cloud Spanner service.
SpannerException.ResourceNotFoundException - Exception in com.google.cloud.spanner
Base exception type for NOT_FOUND exceptions for known resource types.
SpannerExceptionFactory - Class in com.google.cloud.spanner
A factory for creating instances of SpannerException and its subtypes.
SpannerExceptionFactory() - Constructor for class com.google.cloud.spanner.SpannerExceptionFactory
 
SpannerFactory - Interface in com.google.cloud.spanner
Factory to create instance of Spanner.
SpannerInterceptorProvider - Class in com.google.cloud.spanner.spi.v1
For internal use only.
SpannerOptions - Class in com.google.cloud.spanner
Options for the Cloud Spanner service.
SpannerOptions.Builder - Class in com.google.cloud.spanner
Builder for SpannerOptions instances.
SpannerOptions.CallContextConfigurator - Interface in com.google.cloud.spanner
SpannerOptions.CallContextConfigurator can be used to modify the ApiCallContext for one or more specific RPCs.
SpannerOptions.CallCredentialsProvider - Interface in com.google.cloud.spanner
Interface that can be used to provide CallCredentials instead of Credentials to SpannerOptions.
SpannerOptions.SpannerCallContextTimeoutConfigurator - Class in com.google.cloud.spanner
Helper class to configure timeouts for specific Spanner RPCs.
SpannerOptions.SpannerEnvironment - Interface in com.google.cloud.spanner
The environment to read configuration values from.
SpannerPool - Class in com.google.cloud.spanner.connection
Pool for keeping track of Spanner instances needed for connections.
SpannerRpc - Interface in com.google.cloud.spanner.spi.v1
Abstracts remote calls to the Cloud Spanner service.
SpannerRpc.Option - Enum in com.google.cloud.spanner.spi.v1
Options passed in SpannerRpc methods to control how an RPC is issued.
SpannerRpc.Paginated<T> - Class in com.google.cloud.spanner.spi.v1
Represents results from paginated RPCs, i.e., those where up to a maximum number of items is returned from each call and a followup call must be made to fetch more.
SpannerRpc.ResultStreamConsumer - Interface in com.google.cloud.spanner.spi.v1
Consumer for the results produced by a streaming read or query call.
SpannerRpc.StreamingCall - Interface in com.google.cloud.spanner.spi.v1
Handle for cancellation of a streaming read or query call.
SpannerRpcFactory - Interface in com.google.cloud.spanner.spi
Factory to create instances of SpannerRpc.
SpannerSettings - Class in com.google.cloud.spanner.v1
Settings class to configure an instance of SpannerClient.
SpannerSettings(SpannerSettings.Builder) - Constructor for class com.google.cloud.spanner.v1.SpannerSettings
 
SpannerSettings.Builder - Class in com.google.cloud.spanner.v1
Builder for SpannerSettings.
SpannerStub - Class in com.google.cloud.spanner.v1.stub
Base stub class for the Spanner service API.
SpannerStub() - Constructor for class com.google.cloud.spanner.v1.stub.SpannerStub
 
SpannerStubSettings - Class in com.google.cloud.spanner.v1.stub
Settings class to configure an instance of SpannerStub.
SpannerStubSettings(SpannerStubSettings.Builder) - Constructor for class com.google.cloud.spanner.v1.stub.SpannerStubSettings
 
SpannerStubSettings.Builder - Class in com.google.cloud.spanner.v1.stub
Builder for SpannerStubSettings.
startBatchDdl() - Method in interface com.google.cloud.spanner.connection.Connection
Starts a new DDL batch on this connection.
startBatchDml() - Method in interface com.google.cloud.spanner.connection.Connection
Starts a new DML batch on this connection.
Statement - Class in com.google.cloud.spanner
A SQL statement and optional bound parameters that can be executed in a ReadContext.
Statement.Builder - Class in com.google.cloud.spanner
Builder for Statement.
StatementParser - Class in com.google.cloud.spanner.connection
Internal class for the Spanner Connection API.
StatementResult - Interface in com.google.cloud.spanner.connection
A result of the execution of a statement.
StatementResult.ClientSideStatementType - Enum in com.google.cloud.spanner.connection
The type of client side statement that was executed.
StatementResult.ResultType - Enum in com.google.cloud.spanner.connection
Enum indicating the type of result that was returned by Connection.execute(com.google.cloud.spanner.Statement)
streamingReadCallable() - Method in class com.google.cloud.spanner.v1.SpannerClient
Like [Read][google.spanner.v1.Spanner.Read], except returns the result set as a stream.
streamingReadCallable() - Method in class com.google.cloud.spanner.v1.stub.GrpcSpannerStub
 
streamingReadCallable() - Method in class com.google.cloud.spanner.v1.stub.SpannerStub
 
streamingReadSettings() - Method in class com.google.cloud.spanner.v1.SpannerSettings.Builder
Returns the builder for the settings used for calls to streamingRead.
streamingReadSettings() - Method in class com.google.cloud.spanner.v1.SpannerSettings
Returns the object with the settings used for calls to streamingRead.
streamingReadSettings() - Method in class com.google.cloud.spanner.v1.stub.SpannerStubSettings.Builder
Returns the builder for the settings used for calls to streamingRead.
streamingReadSettings() - Method in class com.google.cloud.spanner.v1.stub.SpannerStubSettings
Returns the object with the settings used for calls to streamingRead.
string() - Static method in class com.google.cloud.spanner.Type
Returns the descriptor for the STRING type: a variable-length Unicode character string.
string(String) - Static method in class com.google.cloud.spanner.Value
Returns a STRING value.
stringArray(Iterable<String>) - Static method in class com.google.cloud.spanner.Value
Returns an ARRAY<STRING> value.
strong() - Static method in class com.google.cloud.spanner.TimestampBound
Returns a timestamp bound that will perform reads and queries at a timestamp where all previously committed transactions are visible.
Struct - Class in com.google.cloud.spanner
Represents a non-NULL value of Type.Code.STRUCT.
struct(Iterable<Type.StructField>) - Static method in class com.google.cloud.spanner.Type
Returns a descriptor for a STRUCT type: an ordered collection of named and typed fields.
struct(Type.StructField...) - Static method in class com.google.cloud.spanner.Type
Returns a descriptor for a STRUCT type: an ordered collection of named and typed fields.
struct(Struct) - Static method in class com.google.cloud.spanner.Value
Returns a non-NULL {#code STRUCT} value.
struct(Type, Struct) - Static method in class com.google.cloud.spanner.Value
Returns a STRUCT value of Type type.
Struct.Builder - Class in com.google.cloud.spanner
Builder for constructing non-NULL Struct instances.
structArray(Type, Iterable<Struct>) - Static method in class com.google.cloud.spanner.Value
Returns an ARRAY<STRUCT<...>> value.
StructReader - Interface in com.google.cloud.spanner
A base interface for reading the fields of a STRUCT.

T

testBackupIAMPermissions(String, String, Iterable<String>) - Method in interface com.google.cloud.spanner.DatabaseAdminClient
Tests for the given permissions on the specified backup for the caller.
testDatabaseAdminIAMPermissions(String, Iterable<String>) - Method in class com.google.cloud.spanner.spi.v1.GapicSpannerRpc
 
testDatabaseAdminIAMPermissions(String, Iterable<String>) - Method in interface com.google.cloud.spanner.spi.v1.SpannerRpc
Tests the IAM permissions for the given resource using the DatabaseAdminStub.
testDatabaseIAMPermissions(String, String, Iterable<String>) - Method in interface com.google.cloud.spanner.DatabaseAdminClient
Tests for the given permissions on the specified database for the caller.
testIamPermissions(ResourceName, List<String>) - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Returns permissions that the caller has on the specified database or backup resource.
testIamPermissions(String, List<String>) - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Returns permissions that the caller has on the specified database or backup resource.
testIamPermissions(TestIamPermissionsRequest) - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Returns permissions that the caller has on the specified database or backup resource.
testIamPermissions(ResourceName, List<String>) - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminClient
Returns permissions that the caller has on the specified instance resource.
testIamPermissions(String, List<String>) - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminClient
Returns permissions that the caller has on the specified instance resource.
testIamPermissions(TestIamPermissionsRequest) - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminClient
Returns permissions that the caller has on the specified instance resource.
testIAMPermissions(Iterable<String>) - Method in class com.google.cloud.spanner.Backup
Tests for the given permissions on this backup for the caller.
testIAMPermissions(Iterable<String>) - Method in class com.google.cloud.spanner.Database
Tests for the given permissions on this database for the caller.
testIAMPermissions(Iterable<String>) - Method in class com.google.cloud.spanner.Instance
Tests for the given permissions on this instance for the caller.
testIamPermissionsCallable() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Returns permissions that the caller has on the specified database or backup resource.
testIamPermissionsCallable() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStub
 
testIamPermissionsCallable() - Method in class com.google.cloud.spanner.admin.database.v1.stub.GrpcDatabaseAdminStub
 
testIamPermissionsCallable() - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminClient
Returns permissions that the caller has on the specified instance resource.
testIamPermissionsCallable() - Method in class com.google.cloud.spanner.admin.instance.v1.stub.GrpcInstanceAdminStub
 
testIamPermissionsCallable() - Method in class com.google.cloud.spanner.admin.instance.v1.stub.InstanceAdminStub
 
testIamPermissionsSettings() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminSettings.Builder
Returns the builder for the settings used for calls to testIamPermissions.
testIamPermissionsSettings() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminSettings
Returns the object with the settings used for calls to testIamPermissions.
testIamPermissionsSettings() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStubSettings.Builder
Returns the builder for the settings used for calls to testIamPermissions.
testIamPermissionsSettings() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStubSettings
Returns the object with the settings used for calls to testIamPermissions.
testIamPermissionsSettings() - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminSettings.Builder
Returns the builder for the settings used for calls to testIamPermissions.
testIamPermissionsSettings() - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminSettings
Returns the object with the settings used for calls to testIamPermissions.
testIamPermissionsSettings() - Method in class com.google.cloud.spanner.admin.instance.v1.stub.InstanceAdminStubSettings.Builder
Returns the builder for the settings used for calls to testIamPermissions.
testIamPermissionsSettings() - Method in class com.google.cloud.spanner.admin.instance.v1.stub.InstanceAdminStubSettings
Returns the object with the settings used for calls to testIamPermissions.
testInstanceAdminIAMPermissions(String, Iterable<String>) - Method in class com.google.cloud.spanner.spi.v1.GapicSpannerRpc
 
testInstanceAdminIAMPermissions(String, Iterable<String>) - Method in interface com.google.cloud.spanner.spi.v1.SpannerRpc
Tests the IAM permissions for the given resource using the InstanceAdminStub.
testInstanceIAMPermissions(String, Iterable<String>) - Method in interface com.google.cloud.spanner.InstanceAdminClient
Tests for the given permissions on the specified instance for the caller.
then(AsyncTransactionManager.AsyncTransactionFunction<O, RES>, Executor) - Method in interface com.google.cloud.spanner.AsyncTransactionManager.AsyncTransactionStep
Adds a step to the transaction chain that should be executed using the specified executor.
then(AsyncTransactionManager.AsyncTransactionFunction<Void, O>, Executor) - Method in interface com.google.cloud.spanner.AsyncTransactionManager.TransactionContextFuture
Sets the first step to execute as part of this transaction after the transaction has started using the specified executor.
timestamp() - Static method in class com.google.cloud.spanner.Type
Returns the descriptor for the TIMESTAMP type: a nano precision timestamp in the range [0000-01-01 00:00:00, 9999-12-31 23:59:59.999999999 UTC].
timestamp(Timestamp) - Static method in class com.google.cloud.spanner.Value
Returns a TIMESTAMP value.
timestampArray(Iterable<Timestamp>) - Static method in class com.google.cloud.spanner.Value
Returns an ARRAY<TIMESTAMP> value.
TimestampBound - Class in com.google.cloud.spanner
Defines how Cloud Spanner will choose a timestamp for a read-only transaction or a single read/query.
TimestampBound.Mode - Enum in com.google.cloud.spanner
The type of timestamp bound.
to(Value) - Method in class com.google.cloud.spanner.ValueBinder
Binds a Value
to(boolean) - Method in class com.google.cloud.spanner.ValueBinder
Binds to Value.bool(value)
to(Boolean) - Method in class com.google.cloud.spanner.ValueBinder
Binds to Value.bool(value)
to(long) - Method in class com.google.cloud.spanner.ValueBinder
Binds to Value.int64(value)
to(Long) - Method in class com.google.cloud.spanner.ValueBinder
Binds to Value.int64(value)
to(double) - Method in class com.google.cloud.spanner.ValueBinder
Binds to Value.float64(value)
to(Double) - Method in class com.google.cloud.spanner.ValueBinder
Binds to Value.float64(value)
to(BigDecimal) - Method in class com.google.cloud.spanner.ValueBinder
Binds to Value.numeric(value)
to(String) - Method in class com.google.cloud.spanner.ValueBinder
Binds to Value.string(value)
to(ByteArray) - Method in class com.google.cloud.spanner.ValueBinder
Binds to Value.bytes(value)
to(Timestamp) - Method in class com.google.cloud.spanner.ValueBinder
Binds to Value.timestamp(value)
to(Date) - Method in class com.google.cloud.spanner.ValueBinder
Binds to Value.date(value)
to(Struct) - Method in class com.google.cloud.spanner.ValueBinder
Binds a non-NULL struct value to Value.struct(value)
to(Type, Struct) - Method in class com.google.cloud.spanner.ValueBinder
Binds a nullable Struct reference with given Type to Value.struct(type,value
toAsyncResultSet(ResultSet) - Static method in class com.google.cloud.spanner.ResultSets
Converts the given ResultSet to an AsyncResultSet.
toAsyncResultSet(ResultSet, ExecutorProvider, Options.QueryOption...) - Static method in class com.google.cloud.spanner.ResultSets
Converts the given ResultSet to an AsyncResultSet using the given ExecutorProvider.
toAsyncResultSet(ApiFuture<ResultSet>, ExecutorProvider, Options.QueryOption...) - Static method in class com.google.cloud.spanner.ResultSets
Converts the ResultSet that will be returned by the given ApiFuture to an AsyncResultSet using the given ExecutorProvider.
toBoolArray(boolean[]) - Method in class com.google.cloud.spanner.ValueBinder
Binds to Value.boolArray(values)
toBoolArray(boolean[], int, int) - Method in class com.google.cloud.spanner.ValueBinder
Binds to Value.boolArray(values, int, pos)
toBoolArray(Iterable<Boolean>) - Method in class com.google.cloud.spanner.ValueBinder
Binds to Value.boolArray(values)
toBuilder() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminSettings
Returns a builder containing all the values of this settings class.
toBuilder() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStubSettings
Returns a builder containing all the values of this settings class.
toBuilder() - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminSettings
Returns a builder containing all the values of this settings class.
toBuilder() - Method in class com.google.cloud.spanner.admin.instance.v1.stub.InstanceAdminStubSettings
Returns a builder containing all the values of this settings class.
toBuilder() - Method in class com.google.cloud.spanner.Backup
 
toBuilder() - Method in class com.google.cloud.spanner.Instance
 
toBuilder() - Method in class com.google.cloud.spanner.InstanceInfo
 
toBuilder() - Method in class com.google.cloud.spanner.Key
Returns a builder initialized with the value of this key.
toBuilder() - Method in class com.google.cloud.spanner.KeyRange
Returns a builder initialized with the value of this range.
toBuilder() - Method in class com.google.cloud.spanner.KeySet
Returns a builder initialized with the contents of this set.
toBuilder() - Method in class com.google.cloud.spanner.SpannerOptions
 
toBuilder() - Method in class com.google.cloud.spanner.Statement
 
toBuilder() - Method in class com.google.cloud.spanner.v1.SpannerSettings
Returns a builder containing all the values of this settings class.
toBuilder() - Method in class com.google.cloud.spanner.v1.stub.SpannerStubSettings
Returns a builder containing all the values of this settings class.
toBytesArray(Iterable<ByteArray>) - Method in class com.google.cloud.spanner.ValueBinder
Binds to Value.bytesArray(values)
toDateArray(Iterable<Date>) - Method in class com.google.cloud.spanner.ValueBinder
Binds to Value.dateArray(values)
toFloat64Array(double[]) - Method in class com.google.cloud.spanner.ValueBinder
Binds to Value.float64Array(values)
toFloat64Array(double[], int, int) - Method in class com.google.cloud.spanner.ValueBinder
Binds to Value.float64Array(values, pos, length)
toFloat64Array(Iterable<Double>) - Method in class com.google.cloud.spanner.ValueBinder
Binds to Value.float64Array(values)
toInt64Array(long[]) - Method in class com.google.cloud.spanner.ValueBinder
Binds to Value.int64Array(values)
toInt64Array(long[], int, int) - Method in class com.google.cloud.spanner.ValueBinder
Binds to Value.int64Array(values, pos, length)
toInt64Array(Iterable<Long>) - Method in class com.google.cloud.spanner.ValueBinder
Binds to Value.int64Array(values)
toList(Function<StructReader, T>) - Method in interface com.google.cloud.spanner.AsyncResultSet
Transforms the row cursor into an immutable list using the given transformer function.
toList(Function<StructReader, T>) - Method in class com.google.cloud.spanner.ForwardingAsyncResultSet
 
toListAsync(Function<StructReader, T>, Executor) - Method in interface com.google.cloud.spanner.AsyncResultSet
Transforms the row cursor into an immutable list using the given transformer function.
toListAsync(Function<StructReader, T>, Executor) - Method in class com.google.cloud.spanner.ForwardingAsyncResultSet
 
toNumericArray(Iterable<BigDecimal>) - Method in class com.google.cloud.spanner.ValueBinder
Binds to Value.numericArray(values)
toString() - Method in class com.google.cloud.spanner.BackupId
 
toString() - Method in class com.google.cloud.spanner.BackupInfo
 
toString() - Method in class com.google.cloud.spanner.BatchTransactionId
 
toString() - Method in class com.google.cloud.spanner.connection.ConnectionOptions
 
toString() - Method in enum com.google.cloud.spanner.connection.TransactionMode
 
toString() - Method in class com.google.cloud.spanner.DatabaseId
 
toString() - Method in class com.google.cloud.spanner.DatabaseInfo
 
toString() - Method in class com.google.cloud.spanner.InstanceConfigId
 
toString() - Method in class com.google.cloud.spanner.InstanceConfigInfo
 
toString() - Method in class com.google.cloud.spanner.InstanceId
 
toString() - Method in class com.google.cloud.spanner.InstanceInfo
 
toString() - Method in class com.google.cloud.spanner.Key
 
toString() - Method in class com.google.cloud.spanner.KeyRange
 
toString() - Method in class com.google.cloud.spanner.KeySet
 
toString() - Method in class com.google.cloud.spanner.Mutation
 
toString() - Method in class com.google.cloud.spanner.Options
 
toString() - Method in class com.google.cloud.spanner.Partition
 
toString() - Method in class com.google.cloud.spanner.PartitionOptions
 
toString() - Method in enum com.google.cloud.spanner.spi.v1.SpannerRpc.Option
 
toString() - Method in class com.google.cloud.spanner.Statement
 
toString() - Method in class com.google.cloud.spanner.TimestampBound
 
toString() - Method in class com.google.cloud.spanner.Type
 
toString() - Method in class com.google.cloud.spanner.Value
 
toStringArray(Iterable<String>) - Method in class com.google.cloud.spanner.ValueBinder
Binds to Value.stringArray(values)
toStructArray(Type, Iterable<Struct>) - Method in class com.google.cloud.spanner.ValueBinder
Binds to Value.structArray(fieldTypes, values)
toTimestampArray(Iterable<Timestamp>) - Method in class com.google.cloud.spanner.ValueBinder
Binds to Value.timestampArray(values)
TransactionContext - Interface in com.google.cloud.spanner
Context for a single attempt of a locking read-write transaction.
transactionManager(Options.TransactionOption...) - Method in interface com.google.cloud.spanner.DatabaseClient
Returns a transaction manager which allows manual management of transaction lifecycle.
TransactionManager - Interface in com.google.cloud.spanner
An interface for managing the life cycle of a read write transaction including all its retries.
TransactionManager.TransactionState - Enum in com.google.cloud.spanner
State of the transaction manager.
transactionManagerAsync(Options.TransactionOption...) - Method in interface com.google.cloud.spanner.DatabaseClient
Returns an asynchronous transaction manager which allows manual management of transaction lifecycle.
TransactionMode - Enum in com.google.cloud.spanner.connection
Enum used to define the transaction type of a Connection
TransactionRetryListener - Interface in com.google.cloud.spanner.connection
Cloud Spanner can abort any read/write transaction because of potential deadlocks or other internal reasons.
TransactionRetryListener.RetryResult - Enum in com.google.cloud.spanner.connection
The result of a retry.
TransactionRunner - Interface in com.google.cloud.spanner
An interface for executing a body of work in the context of a read-write transaction, with retries for transaction aborts.
TransactionRunner.TransactionCallable<T> - Interface in com.google.cloud.spanner
A unit of work to be performed in the context of a transaction.
tryNext() - Method in interface com.google.cloud.spanner.AsyncResultSet
Non-blocking call that attempts to step the cursor to the next position in the stream.
tryNext() - Method in class com.google.cloud.spanner.ForwardingAsyncResultSet
 
Type - Class in com.google.cloud.spanner
Describes a type in the Cloud Spanner type system.
Type.Code - Enum in com.google.cloud.spanner
Enumerates the categories of types.
Type.StructField - Class in com.google.cloud.spanner
Describes an individual field in a STRUCT type.

U

unaryMethodSettingsBuilders() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStubSettings.Builder
 
unaryMethodSettingsBuilders() - Method in class com.google.cloud.spanner.admin.instance.v1.stub.InstanceAdminStubSettings.Builder
 
unaryMethodSettingsBuilders() - Method in class com.google.cloud.spanner.v1.stub.SpannerStubSettings.Builder
 
update(InstanceInfo.InstanceField...) - Method in class com.google.cloud.spanner.Instance
 
updateBackup(Backup, FieldMask) - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Updates a pending or completed [Backup][google.spanner.admin.database.v1.Backup].
updateBackup(UpdateBackupRequest) - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Updates a pending or completed [Backup][google.spanner.admin.database.v1.Backup].
updateBackup(String, String, Timestamp) - Method in interface com.google.cloud.spanner.DatabaseAdminClient
Updates the expire time of a backup.
updateBackup(Backup, FieldMask) - Method in class com.google.cloud.spanner.spi.v1.GapicSpannerRpc
 
updateBackup(Backup, FieldMask) - Method in interface com.google.cloud.spanner.spi.v1.SpannerRpc
Updates the specified backup.
updateBackupCallable() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Updates a pending or completed [Backup][google.spanner.admin.database.v1.Backup].
updateBackupCallable() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStub
 
updateBackupCallable() - Method in class com.google.cloud.spanner.admin.database.v1.stub.GrpcDatabaseAdminStub
 
updateBackupSettings() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminSettings.Builder
Returns the builder for the settings used for calls to updateBackup.
updateBackupSettings() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminSettings
Returns the object with the settings used for calls to updateBackup.
updateBackupSettings() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStubSettings.Builder
Returns the builder for the settings used for calls to updateBackup.
updateBackupSettings() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStubSettings
Returns the object with the settings used for calls to updateBackup.
updateDatabaseDdl(String, String, Iterable<String>, String) - Method in interface com.google.cloud.spanner.DatabaseAdminClient
Enqueues the given DDL statements to be applied, in order but not necessarily all at once, to the database schema at some point (or points) in the future.
updateDatabaseDdl(String, Iterable<String>, String) - Method in class com.google.cloud.spanner.spi.v1.GapicSpannerRpc
If the update database ddl operation returns an ALREADY_EXISTS error, meaning the operation id used is already in flight, this method will simply resume the original operation.
updateDatabaseDdl(String, Iterable<String>, String) - Method in interface com.google.cloud.spanner.spi.v1.SpannerRpc
 
updateDatabaseDdlAsync(DatabaseName, List<String>) - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Updates the schema of a Cloud Spanner database by creating/altering/dropping tables, columns, indexes, etc.
updateDatabaseDdlAsync(String, List<String>) - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Updates the schema of a Cloud Spanner database by creating/altering/dropping tables, columns, indexes, etc.
updateDatabaseDdlAsync(UpdateDatabaseDdlRequest) - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Updates the schema of a Cloud Spanner database by creating/altering/dropping tables, columns, indexes, etc.
updateDatabaseDdlCallable() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Updates the schema of a Cloud Spanner database by creating/altering/dropping tables, columns, indexes, etc.
updateDatabaseDdlCallable() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStub
 
updateDatabaseDdlCallable() - Method in class com.google.cloud.spanner.admin.database.v1.stub.GrpcDatabaseAdminStub
 
updateDatabaseDdlOperationCallable() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminClient
Updates the schema of a Cloud Spanner database by creating/altering/dropping tables, columns, indexes, etc.
updateDatabaseDdlOperationCallable() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStub
 
updateDatabaseDdlOperationCallable() - Method in class com.google.cloud.spanner.admin.database.v1.stub.GrpcDatabaseAdminStub
 
updateDatabaseDdlOperationSettings() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminSettings.Builder
Returns the builder for the settings used for calls to updateDatabaseDdl.
updateDatabaseDdlOperationSettings() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminSettings
Returns the object with the settings used for calls to updateDatabaseDdl.
updateDatabaseDdlOperationSettings() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStubSettings.Builder
Returns the builder for the settings used for calls to updateDatabaseDdl.
updateDatabaseDdlOperationSettings() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStubSettings
Returns the object with the settings used for calls to updateDatabaseDdl.
updateDatabaseDdlSettings() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminSettings.Builder
Returns the builder for the settings used for calls to updateDatabaseDdl.
updateDatabaseDdlSettings() - Method in class com.google.cloud.spanner.admin.database.v1.DatabaseAdminSettings
Returns the object with the settings used for calls to updateDatabaseDdl.
updateDatabaseDdlSettings() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStubSettings.Builder
Returns the builder for the settings used for calls to updateDatabaseDdl.
updateDatabaseDdlSettings() - Method in class com.google.cloud.spanner.admin.database.v1.stub.DatabaseAdminStubSettings
Returns the object with the settings used for calls to updateDatabaseDdl.
updateDdl(Iterable<String>, String) - Method in class com.google.cloud.spanner.Database
Enqueues the given DDL statements to be applied, in order but not necessarily all at once, to the database schema at some point (or points) in the future.
updateExpireTime() - Method in class com.google.cloud.spanner.Backup
Updates the expire time of this backup on Cloud Spanner.
updateInstance(InstanceInfo, InstanceInfo.InstanceField...) - Method in interface com.google.cloud.spanner.InstanceAdminClient
Updates an instance, and begins allocating or releasing resources as requested.
updateInstance(Instance, FieldMask) - Method in class com.google.cloud.spanner.spi.v1.GapicSpannerRpc
 
updateInstance(Instance, FieldMask) - Method in interface com.google.cloud.spanner.spi.v1.SpannerRpc
 
updateInstanceAsync(Instance, FieldMask) - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminClient
Updates an instance, and begins allocating or releasing resources as requested.
updateInstanceAsync(UpdateInstanceRequest) - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminClient
Updates an instance, and begins allocating or releasing resources as requested.
updateInstanceCallable() - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminClient
Updates an instance, and begins allocating or releasing resources as requested.
updateInstanceCallable() - Method in class com.google.cloud.spanner.admin.instance.v1.stub.GrpcInstanceAdminStub
 
updateInstanceCallable() - Method in class com.google.cloud.spanner.admin.instance.v1.stub.InstanceAdminStub
 
updateInstanceOperationCallable() - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminClient
Updates an instance, and begins allocating or releasing resources as requested.
updateInstanceOperationCallable() - Method in class com.google.cloud.spanner.admin.instance.v1.stub.GrpcInstanceAdminStub
 
updateInstanceOperationCallable() - Method in class com.google.cloud.spanner.admin.instance.v1.stub.InstanceAdminStub
 
updateInstanceOperationSettings() - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminSettings.Builder
Returns the builder for the settings used for calls to updateInstance.
updateInstanceOperationSettings() - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminSettings
Returns the object with the settings used for calls to updateInstance.
updateInstanceOperationSettings() - Method in class com.google.cloud.spanner.admin.instance.v1.stub.InstanceAdminStubSettings.Builder
Returns the builder for the settings used for calls to updateInstance.
updateInstanceOperationSettings() - Method in class com.google.cloud.spanner.admin.instance.v1.stub.InstanceAdminStubSettings
Returns the object with the settings used for calls to updateInstance.
updateInstanceSettings() - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminSettings.Builder
Returns the builder for the settings used for calls to updateInstance.
updateInstanceSettings() - Method in class com.google.cloud.spanner.admin.instance.v1.InstanceAdminSettings
Returns the object with the settings used for calls to updateInstance.
updateInstanceSettings() - Method in class com.google.cloud.spanner.admin.instance.v1.stub.InstanceAdminStubSettings.Builder
Returns the builder for the settings used for calls to updateInstance.
updateInstanceSettings() - Method in class com.google.cloud.spanner.admin.instance.v1.stub.InstanceAdminStubSettings
Returns the object with the settings used for calls to updateInstance.
useDefaultEnvironment() - Static method in class com.google.cloud.spanner.SpannerOptions
Sets the environment to use to read configuration to the default environment.
useEnvironment(SpannerOptions.SpannerEnvironment) - Static method in class com.google.cloud.spanner.SpannerOptions
Sets the environment to use to read configuration.

V

VALID_PROPERTIES - Static variable in class com.google.cloud.spanner.connection.ConnectionOptions
All valid connection properties.
Value - Class in com.google.cloud.spanner
Represents a value to be consumed by the Cloud Spanner API.
ValueBinder<R> - Class in com.google.cloud.spanner
An interface for binding a Value in some context.
valueOf(String) - Static method in enum com.google.cloud.spanner.AsyncResultSet.CallbackResponse
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.cloud.spanner.AsyncResultSet.CursorState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.cloud.spanner.BackupInfo.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.cloud.spanner.connection.AutocommitDmlMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.cloud.spanner.connection.StatementResult.ClientSideStatementType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.cloud.spanner.connection.StatementResult.ResultType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.cloud.spanner.connection.TransactionMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.cloud.spanner.connection.TransactionRetryListener.RetryResult
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.cloud.spanner.DatabaseInfo.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.cloud.spanner.ErrorCode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.cloud.spanner.InstanceInfo.InstanceField
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.cloud.spanner.InstanceInfo.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.cloud.spanner.KeyRange.Endpoint
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.cloud.spanner.Mutation.Op
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.cloud.spanner.ReadContext.QueryAnalyzeMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.cloud.spanner.RestoreInfo.RestoreSourceType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.cloud.spanner.spi.v1.SpannerRpc.Option
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.cloud.spanner.TimestampBound.Mode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.cloud.spanner.TransactionManager.TransactionState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.google.cloud.spanner.Type.Code
Returns the enum constant of this type with the specified name.
values() - Static method in enum com.google.cloud.spanner.AsyncResultSet.CallbackResponse
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.google.cloud.spanner.AsyncResultSet.CursorState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.google.cloud.spanner.BackupInfo.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.spanner.connection.AutocommitDmlMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.google.cloud.spanner.connection.StatementResult.ClientSideStatementType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.google.cloud.spanner.connection.StatementResult.ResultType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.google.cloud.spanner.connection.TransactionMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.google.cloud.spanner.connection.TransactionRetryListener.RetryResult
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.google.cloud.spanner.DatabaseInfo.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.spanner.ErrorCode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.google.cloud.spanner.InstanceInfo.InstanceField
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.google.cloud.spanner.InstanceInfo.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.spanner.KeyRange.Endpoint
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.google.cloud.spanner.Mutation.Op
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.google.cloud.spanner.ReadContext.QueryAnalyzeMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.google.cloud.spanner.RestoreInfo.RestoreSourceType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.google.cloud.spanner.spi.v1.SpannerRpc.Option
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.google.cloud.spanner.TimestampBound.Mode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.google.cloud.spanner.TransactionManager.TransactionState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.google.cloud.spanner.Type.Code
Returns an array containing the constants of this enum type, in the order they are declared.

W

waitFor(RetryOption...) - Method in class com.google.cloud.spanner.Operation
Blocks till the operation is complete or maximum time, if specified, has elapsed.
with(ClientInterceptor) - Method in class com.google.cloud.spanner.spi.v1.SpannerInterceptorProvider
 
withBatchUpdateTimeout(Duration) - Method in class com.google.cloud.spanner.SpannerOptions.SpannerCallContextTimeoutConfigurator
 
withCommitTimeout(Duration) - Method in class com.google.cloud.spanner.SpannerOptions.SpannerCallContextTimeoutConfigurator
 
withExecuteQueryTimeout(Duration) - Method in class com.google.cloud.spanner.SpannerOptions.SpannerCallContextTimeoutConfigurator
 
withExecuteUpdateTimeout(Duration) - Method in class com.google.cloud.spanner.SpannerOptions.SpannerCallContextTimeoutConfigurator
 
withPartitionQueryTimeout(Duration) - Method in class com.google.cloud.spanner.SpannerOptions.SpannerCallContextTimeoutConfigurator
 
withPartitionReadTimeout(Duration) - Method in class com.google.cloud.spanner.SpannerOptions.SpannerCallContextTimeoutConfigurator
 
withQueryOptions(ExecuteSqlRequest.QueryOptions) - Method in class com.google.cloud.spanner.Statement.Builder
Sets the ExecuteSqlRequest.QueryOptions to use when executing this Statement.
withReadTimeout(Duration) - Method in class com.google.cloud.spanner.SpannerOptions.SpannerCallContextTimeoutConfigurator
 
withRollbackTimeout(Duration) - Method in class com.google.cloud.spanner.SpannerOptions.SpannerCallContextTimeoutConfigurator
 
write(Mutation) - Method in interface com.google.cloud.spanner.connection.Connection
Writes the specified mutation directly to the database and commits the change.
write(Iterable<Mutation>) - Method in interface com.google.cloud.spanner.connection.Connection
Writes the specified mutations directly to the database and commits the changes.
write(Iterable<Mutation>) - Method in interface com.google.cloud.spanner.DatabaseClient
Writes the given mutations atomically to the database.
writeAsync(Mutation) - Method in interface com.google.cloud.spanner.connection.Connection
Writes the specified mutation directly to the database and commits the change.
writeAsync(Iterable<Mutation>) - Method in interface com.google.cloud.spanner.connection.Connection
Writes the specified mutations directly to the database and commits the changes.
writeAtLeastOnce(Iterable<Mutation>) - Method in interface com.google.cloud.spanner.DatabaseClient
Writes the given mutations atomically to the database without replay protection.
writeAtLeastOnceWithOptions(Iterable<Mutation>, Options.TransactionOption...) - Method in interface com.google.cloud.spanner.DatabaseClient
Writes the given mutations atomically to the database without replay protection.
writeWithOptions(Iterable<Mutation>, Options.TransactionOption...) - Method in interface com.google.cloud.spanner.DatabaseClient
Writes the given mutations atomically to the database with the given options.
A B C D E F G H I K L M N O P R S T U V W 
Skip navigation links

Copyright © 2021 Google LLC. All rights reserved.