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

A

abort() - Method in interface com.palantir.atlasdb.transaction.api.Transaction
Aborts the transaction.
aborted() - Method in interface com.palantir.atlasdb.transaction.service.TransactionStatus.Cases
 
acceptorLogDir() - Method in class com.palantir.atlasdb.config.LeaderConfig
 
accumulateWith(SweepResults) - Method in class com.palantir.atlasdb.keyvalue.api.SweepResults
Returns a new SweepResults representing cumulative results from this instance and other.
acquireFromSharedPoolTimeoutInSeconds() - Method in interface com.palantir.atlasdb.spi.LocalConnectionConfig
 
addGarbageCollectionSentinelValues(TableReference, Iterable<Cell>) - Method in interface com.palantir.atlasdb.keyvalue.api.KeyValueService
Adds a value with timestamp = Value.INVALID_VALUE_TIMESTAMP to each of the given cells.
addIfNotEmpty(MoreObjects.ToStringHelper, String, byte[]) - Static method in class com.palantir.atlasdb.encoding.PtBytes
 
addMetricFilter(MetricName, MetricPublicationFilter) - Method in class com.palantir.atlasdb.util.MetricsManager
 
addMetricFilter(Class<?>, String, Map<String, String>, MetricPublicationFilter) - Method in class com.palantir.atlasdb.util.MetricsManager
 
AGGRESSIVE_HARD_DELETE - com.palantir.atlasdb.transaction.api.Transaction.TransactionType
In addition to queuing cells for "scrubbing", we also: - (a) Scrub earlier than we would have otherwise, even at the cost of possibly causing open transactions to abort, and - (b) Block until the scrub is complete.
all() - Static method in class com.palantir.atlasdb.keyvalue.api.ColumnSelection
 
all() - Static method in class com.palantir.atlasdb.keyvalue.api.RangeRequest
 
ALL_AVAILABLE - com.palantir.atlasdb.keyvalue.api.ClusterAvailabilityStatus
 
allColumnsSelected() - Method in class com.palantir.atlasdb.keyvalue.api.ColumnSelection
 
asCellsForRows(Iterable<byte[]>) - Method in class com.palantir.atlasdb.keyvalue.api.ColumnSelection
 
asLockAware(TransactionTask<T, E>) - Static method in class com.palantir.atlasdb.transaction.api.LockAwareTransactionTasks
 
asLockUnaware(LockAwareTransactionTask<T, E>) - Static method in class com.palantir.atlasdb.transaction.api.LockAwareTransactionTasks
 
asLockUnaware(LockAwareTransactionTask<T, E>, Iterable<HeldLocksToken>) - Static method in class com.palantir.atlasdb.transaction.api.LockAwareTransactionTasks
 
AsyncKeyValueService - Interface in com.palantir.atlasdb.keyvalue.api
 
AsyncTransactionService - Interface in com.palantir.atlasdb.transaction.service
 
AtlasDbConstraintCheckingMode - Enum in com.palantir.atlasdb.transaction.api
 
AtlasDbFactory - Interface in com.palantir.atlasdb.spi
 
AtlasDbVersion - Class in com.palantir.atlasdb.versions
 
AtlasLockDescriptorUtils - Class in com.palantir.atlasdb.keyvalue.api
 
AtlasLockDescriptorUtils.TableRefAndRemainder - Interface in com.palantir.atlasdb.keyvalue.api
 

B

BatchColumnRangeSelection - Class in com.palantir.atlasdb.keyvalue.api
 
batchHint(Integer) - Method in class com.palantir.atlasdb.keyvalue.api.RangeRequest.Builder
This is a hint for how much data the underlying system should process at a time.
batchSizeHint() - Method in interface com.palantir.atlasdb.keyvalue.api.CandidateCellForSweepingRequest
 
build() - Method in class com.palantir.atlasdb.keyvalue.api.RangeRequest.Builder
 
builder() - Static method in interface com.palantir.atlasdb.keyvalue.api.MultiCheckAndSetRequest
 
builder() - Static method in class com.palantir.atlasdb.keyvalue.api.RangeRequest
Returns a RangeRequest.Builder instance, a helper class for instantiating immutable RangeRequest objects.
builder() - Static method in class com.palantir.atlasdb.keyvalue.api.SweepResults
 
builder() - Static method in class com.palantir.atlasdb.spi.DerivedSnapshotConfig
 
builder(boolean) - Static method in class com.palantir.atlasdb.keyvalue.api.RangeRequest
 
Builder() - Constructor for class com.palantir.atlasdb.keyvalue.api.CheckAndSetRequest.Builder
 
Builder() - Constructor for class com.palantir.atlasdb.keyvalue.api.SweepResults.Builder
 
Builder() - Constructor for class com.palantir.atlasdb.keyvalue.api.TimestampRangeDelete.Builder
 
BYTES_COMPARATOR - Static variable in class com.palantir.atlasdb.encoding.PtBytes
 
BYTES_HYDRATOR - Static variable in class com.palantir.atlasdb.keyvalue.api.TargetedSweepMetadata
 
BYTES_TO_HEX_STRING - Static variable in class com.palantir.atlasdb.encoding.PtBytes
 

C

CacheValue - Class in com.palantir.atlasdb.keyvalue.api.cache
 
CandidateCellForSweeping - Interface in com.palantir.atlasdb.keyvalue.api
 
CandidateCellForSweepingRequest - Interface in com.palantir.atlasdb.keyvalue.api
 
candidateCells(LockDescriptor) - Static method in class com.palantir.atlasdb.keyvalue.api.AtlasLockDescriptorUtils
 
canTransactionBeRetried() - Method in exception com.palantir.atlasdb.transaction.api.TransactionFailedException
 
canTransactionBeRetried() - Method in exception com.palantir.atlasdb.transaction.api.TransactionFailedNonRetriableException
 
canTransactionBeRetried() - Method in exception com.palantir.atlasdb.transaction.api.TransactionFailedRetriableException
 
cell() - Method in interface com.palantir.atlasdb.keyvalue.api.CandidateCellForSweeping
 
cell() - Method in class com.palantir.atlasdb.keyvalue.api.CellReference
 
cell() - Method in class com.palantir.atlasdb.keyvalue.api.CheckAndSetRequest
 
Cell - Class in com.palantir.atlasdb.keyvalue.api
Represents a cell in the key-value store.
CellConflict(Cell, long, long) - Constructor for class com.palantir.atlasdb.transaction.api.TransactionConflictException.CellConflict
 
CellConflict(Cell, String, long, long) - Constructor for class com.palantir.atlasdb.transaction.api.TransactionConflictException.CellConflict
 
CellReference - Class in com.palantir.atlasdb.keyvalue.api
 
CellReference() - Constructor for class com.palantir.atlasdb.keyvalue.api.CellReference
 
cellsCleanedUp(Transaction, Set<Cell>) - Method in interface com.palantir.atlasdb.cleaner.api.OnCleanupTask
This method is run in a fresh transaction before a cell is cleaned up.
check() - Method in class com.palantir.atlasdb.config.LeaderConfig
 
check() - Method in interface com.palantir.atlasdb.keyvalue.api.MultiCheckAndSetRequest
 
checkAndSet(CheckAndSetRequest) - Method in interface com.palantir.atlasdb.keyvalue.api.KeyValueService
Performs a check-and-set into the key-value store.
CheckAndSetCompatibility - Interface in com.palantir.atlasdb.keyvalue.api
Indicates whether a KeyValueService supports check and set (CAS) and put unless exists (PUE) operations, and if so the granularity with which it can provide feedback.
CheckAndSetCompatibility.Supported - Class in com.palantir.atlasdb.keyvalue.api
 
CheckAndSetCompatibility.Unsupported - Enum in com.palantir.atlasdb.keyvalue.api
 
CheckAndSetException - Exception in com.palantir.atlasdb.keyvalue.api
 
CheckAndSetException(Cell, TableReference, byte[], List<byte[]>) - Constructor for exception com.palantir.atlasdb.keyvalue.api.CheckAndSetException
 
CheckAndSetException(String) - Constructor for exception com.palantir.atlasdb.keyvalue.api.CheckAndSetException
 
CheckAndSetException(String, Cell, byte[], List<byte[]>) - Constructor for exception com.palantir.atlasdb.keyvalue.api.CheckAndSetException
 
CheckAndSetException(String, Throwable) - Constructor for exception com.palantir.atlasdb.keyvalue.api.CheckAndSetException
 
CheckAndSetException(String, Throwable, Cell, byte[], List<byte[]>) - Constructor for exception com.palantir.atlasdb.keyvalue.api.CheckAndSetException
 
CheckAndSetRequest - Class in com.palantir.atlasdb.keyvalue.api
A request to be supplied to KeyValueService.checkAndSet.
CheckAndSetRequest() - Constructor for class com.palantir.atlasdb.keyvalue.api.CheckAndSetRequest
 
CheckAndSetRequest.Builder - Class in com.palantir.atlasdb.keyvalue.api
 
checkReadWriteConflicts() - Method in enum com.palantir.atlasdb.transaction.api.ConflictHandler
 
checkWriteWriteConflicts() - Method in enum com.palantir.atlasdb.transaction.api.ConflictHandler
 
Cleaner - Interface in com.palantir.atlasdb.cleaner.api
A Cleaner is good for two things: it scrubs and it punches.
cleanup() - Method in interface com.palantir.atlasdb.transaction.api.PreCommitCondition
Cleans up any state managed by this condition, e.g.
clearTimestampCache() - Method in interface com.palantir.atlasdb.transaction.api.TransactionManager
Clear the timestamp cache.
close() - Method in interface com.palantir.atlasdb.cleaner.api.Cleaner
Release resources.
close() - Method in interface com.palantir.atlasdb.keyvalue.api.AsyncKeyValueService
 
close() - Method in interface com.palantir.atlasdb.keyvalue.api.KeyValueService
Performs non-destructive cleanup when the KVS is no longer needed.
close() - Method in class com.palantir.atlasdb.keyvalue.api.watch.LockWatchManagerInternal
 
close() - Method in class com.palantir.atlasdb.keyvalue.api.watch.NoOpLockWatchManager
 
close() - Method in interface com.palantir.atlasdb.transaction.api.TransactionManager
Frees resources used by this TransactionManager, and invokes any callbacks registered to run on close.
close() - Method in interface com.palantir.atlasdb.transaction.service.TransactionService
Frees up resources associated with the transaction service.
ClusterAvailabilityStatus - Enum in com.palantir.atlasdb.keyvalue.api
 
COLUMN_COMPARATOR - Static variable in class com.palantir.atlasdb.keyvalue.api.Cell
 
ColumnRangeSelection - Class in com.palantir.atlasdb.keyvalue.api
 
ColumnRangeSelection(byte[], byte[]) - Constructor for class com.palantir.atlasdb.keyvalue.api.ColumnRangeSelection
 
ColumnRangeSelections - Class in com.palantir.atlasdb.keyvalue.api
 
ColumnSelection - Class in com.palantir.atlasdb.keyvalue.api
 
com.palantir.atlasdb.cleaner.api - package com.palantir.atlasdb.cleaner.api
 
com.palantir.atlasdb.config - package com.palantir.atlasdb.config
 
com.palantir.atlasdb.encoding - package com.palantir.atlasdb.encoding
 
com.palantir.atlasdb.factory - package com.palantir.atlasdb.factory
 
com.palantir.atlasdb.keyvalue.api - package com.palantir.atlasdb.keyvalue.api
 
com.palantir.atlasdb.keyvalue.api.cache - package com.palantir.atlasdb.keyvalue.api.cache
 
com.palantir.atlasdb.keyvalue.api.watch - package com.palantir.atlasdb.keyvalue.api.watch
 
com.palantir.atlasdb.metrics - package com.palantir.atlasdb.metrics
 
com.palantir.atlasdb.persist.api - package com.palantir.atlasdb.persist.api
 
com.palantir.atlasdb.persistent.api - package com.palantir.atlasdb.persistent.api
 
com.palantir.atlasdb.spi - package com.palantir.atlasdb.spi
 
com.palantir.atlasdb.timestamp - package com.palantir.atlasdb.timestamp
 
com.palantir.atlasdb.transaction.api - package com.palantir.atlasdb.transaction.api
 
com.palantir.atlasdb.transaction.service - package com.palantir.atlasdb.transaction.service
 
com.palantir.atlasdb.util - package com.palantir.atlasdb.util
 
com.palantir.atlasdb.versions - package com.palantir.atlasdb.versions
 
commit() - Method in interface com.palantir.atlasdb.transaction.api.Transaction
Commits the transaction.
commit(TransactionService) - Method in interface com.palantir.atlasdb.transaction.api.Transaction
 
committed(long) - Method in interface com.palantir.atlasdb.transaction.service.TransactionStatus.Cases
 
compactInternally(TableReference) - Method in interface com.palantir.atlasdb.keyvalue.api.KeyValueService
Does whatever can be done to compact or cleanup a table.
compactInternally(TableReference, boolean) - Method in interface com.palantir.atlasdb.keyvalue.api.KeyValueService
Some compaction operations might block reads and writes.
compareTo(byte[], byte[]) - Static method in class com.palantir.atlasdb.encoding.PtBytes
Compare two byte arrays.
compareTo(Cell) - Method in class com.palantir.atlasdb.keyvalue.api.Cell
 
concurrencyLevel() - Method in interface com.palantir.atlasdb.transaction.api.GetRangesQuery
Parallelism to run this getRanges query with.
concurrentGetRangesThreadPoolSize() - Method in class com.palantir.atlasdb.spi.DerivedSnapshotConfig
The size of the thread pool used for concurrently running range requests.
concurrentGetRangesThreadPoolSize() - Method in interface com.palantir.atlasdb.spi.KeyValueServiceConfigHelper
 
ConditionAwareTransactionTask<T,​C extends PreCommitCondition,​E extends Exception> - Interface in com.palantir.atlasdb.transaction.api
 
ConflictHandler - Enum in com.palantir.atlasdb.transaction.api
 
connectionConfig() - Method in interface com.palantir.atlasdb.spi.SharedResourcesConfig
 
conservative() - Method in class com.palantir.atlasdb.keyvalue.api.TargetedSweepMetadata
 
consistencyState() - Method in interface com.palantir.atlasdb.factory.TransactionManagerConsistencyResult
 
CONSISTENT - com.palantir.atlasdb.factory.TransactionManagerConsistencyResult.ConsistencyState
Indicates that we did not detect any inconsistencies in the transaction manager.
CONSISTENT_RESULT - Static variable in interface com.palantir.atlasdb.factory.TransactionManagerConsistencyResult
Deprecated.
CONSISTENT_RESULT - Static variable in class com.palantir.atlasdb.factory.TransactionManagerConsistencyResults
 
consistentOnFailure() - Method in interface com.palantir.atlasdb.keyvalue.api.CheckAndSetCompatibility
If true, on CAS or PUE failure other than a CheckAndSetException or a KeyAlreadyExistsException, the values may or may not have been persisted but the state is guaranteed to be consistent: any subsequent reads will be repeatable.
consistentOnFailure() - Method in enum com.palantir.atlasdb.keyvalue.api.CheckAndSetCompatibility.Unsupported
 
ConstraintCheckable - Interface in com.palantir.atlasdb.transaction.api
 
ConstraintCheckingTransaction - Interface in com.palantir.atlasdb.transaction.api
 
contains(byte[]) - Method in class com.palantir.atlasdb.keyvalue.api.ColumnSelection
 
containsColumn(byte[]) - Method in class com.palantir.atlasdb.keyvalue.api.RangeRequest
 
create() - Static method in class com.palantir.atlasdb.keyvalue.api.cache.NoOpTransactionScopedCache
 
create() - Static method in class com.palantir.atlasdb.keyvalue.api.watch.NoOpLockWatchManager
 
create() - Static method in class com.palantir.atlasdb.metrics.MetricPublicationArbiter
 
create(byte[], byte[]) - Static method in class com.palantir.atlasdb.keyvalue.api.Cell
Creates a key.
create(byte[], byte[], int) - Static method in class com.palantir.atlasdb.keyvalue.api.BatchColumnRangeSelection
 
create(byte[], long) - Static method in class com.palantir.atlasdb.keyvalue.api.Value
 
create(byte[], SortedMap<byte[], T>) - Static method in class com.palantir.atlasdb.keyvalue.api.RowResult
 
create(TransactionScopedCache) - Static method in class com.palantir.atlasdb.keyvalue.api.cache.ReadOnlyTransactionScopedCache
 
create(ColumnRangeSelection, int) - Static method in class com.palantir.atlasdb.keyvalue.api.BatchColumnRangeSelection
 
create(Namespace, String) - Static method in class com.palantir.atlasdb.keyvalue.api.TableReference
 
create(TableReference, long, long) - Static method in exception com.palantir.atlasdb.transaction.api.TransactionSerializableConflictException
 
create(TableReference, long, Collection<TransactionConflictException.CellConflict>, Collection<TransactionConflictException.CellConflict>, long) - Static method in exception com.palantir.atlasdb.transaction.api.TransactionConflictException
 
create(Iterable<byte[]>) - Static method in class com.palantir.atlasdb.keyvalue.api.ColumnSelection
 
create(String) - Static method in class com.palantir.atlasdb.keyvalue.api.Namespace
 
create(String, Pattern) - Static method in class com.palantir.atlasdb.keyvalue.api.Namespace
 
createDerivedSnapshotConfig(KeyValueServiceConfig, Optional<KeyValueServiceRuntimeConfig>) - Method in interface com.palantir.atlasdb.spi.AtlasDbFactory
Creates a DerivedSnapshotConfig that is derived from a KeyValueServiceConfig, and where necessary, a snapshot of a KeyValueServiceRuntimeConfig.
createEmptySweepResult(Optional<byte[]>) - Static method in class com.palantir.atlasdb.keyvalue.api.SweepResults
 
createEmptySweepResultWithMoreToSweep() - Static method in class com.palantir.atlasdb.keyvalue.api.SweepResults
 
createEmptySweepResultWithNoMoreToSweep() - Static method in class com.palantir.atlasdb.keyvalue.api.SweepResults
 
createEndNameForPrefixScan(byte[]) - Static method in class com.palantir.atlasdb.keyvalue.api.RangeRequests
This will return the row name that will include exactly all prefix matches if passed to KeyValueService.getRange(TableReference, RangeRequest, long).
createFromFullyQualifiedName(String) - Static method in class com.palantir.atlasdb.keyvalue.api.TableReference
Creates a table reference based on fullTableName.
createLowerCased(TableReference) - Static method in class com.palantir.atlasdb.keyvalue.api.TableReference
 
createManagedTimestampService(KeyValueService, DbTimestampCreationSetting, boolean) - Method in interface com.palantir.atlasdb.timestamp.DbTimeLockFactory
 
createManagedTimestampService(KeyValueService, Optional<TableReference>, boolean) - Method in interface com.palantir.atlasdb.spi.AtlasDbFactory
 
createPrefixRange(byte[], int) - Static method in class com.palantir.atlasdb.keyvalue.api.ColumnRangeSelections
 
createPrefixRange(Persistable, int) - Static method in class com.palantir.atlasdb.keyvalue.api.ColumnRangeSelections
 
createRawKeyValueService(MetricsManager, KeyValueServiceConfig, Refreshable<Optional<KeyValueServiceRuntimeConfig>>, LeaderConfig, boolean) - Method in interface com.palantir.atlasdb.timestamp.DbTimeLockFactory
 
createRawKeyValueService(MetricsManager, KeyValueServiceConfig, Refreshable<Optional<KeyValueServiceRuntimeConfig>>, Optional<LeaderConfig>, Optional<String>, LongSupplier, boolean) - Method in interface com.palantir.atlasdb.spi.AtlasDbFactory
Creates a KeyValueService instance of type according to the config parameter.
createReadOnlyCache(CommitUpdate) - Method in class com.palantir.atlasdb.keyvalue.api.cache.NoOpTransactionScopedCache
 
createReadOnlyCache(CommitUpdate) - Method in class com.palantir.atlasdb.keyvalue.api.cache.ReadOnlyTransactionScopedCache
 
createReadOnlyCache(CommitUpdate) - Method in interface com.palantir.atlasdb.keyvalue.api.cache.TransactionScopedCache
 
createSpace() - Method in interface com.palantir.atlasdb.persistent.api.PersistentStore
Creates a store space to be used to store key-value pairs.
createTable(TableReference, byte[]) - Method in interface com.palantir.atlasdb.keyvalue.api.KeyValueService
Creates a table with the specified name.
createTables(Map<TableReference, byte[]>) - Method in interface com.palantir.atlasdb.keyvalue.api.KeyValueService
Creates many tables in idempotent fashion.
createTimestampSeriesProvider(KeyValueService, TableReference, boolean) - Method in interface com.palantir.atlasdb.timestamp.DbTimeLockFactory
 
createTimestampStoreInvalidator(KeyValueService, Optional<TableReference>) - Method in interface com.palantir.atlasdb.spi.AtlasDbFactory
 
createUnsafe(String) - Static method in class com.palantir.atlasdb.keyvalue.api.TableReference
Deprecated.
please use createFromFullyQualifiedName, if fullTableName includes the namespace, or createWithEmptyNamespace, if you're passing in a system table name.
createWithCopyOfData(byte[], long) - Static method in class com.palantir.atlasdb.keyvalue.api.Value
 
createWithEmptyNamespace(String) - Static method in class com.palantir.atlasdb.keyvalue.api.TableReference
Creates a table reference with an empty namespace, based on tablename.

D

DbTimeLockFactory - Interface in com.palantir.atlasdb.timestamp
DbTimestampCreationSetting - Interface in com.palantir.atlasdb.config
 
decodeBase64(String) - Static method in class com.palantir.atlasdb.encoding.PtBytes
 
decodeHexString(String) - Static method in class com.palantir.atlasdb.encoding.PtBytes
 
dedicatedRow() - Method in class com.palantir.atlasdb.keyvalue.api.TargetedSweepMetadata
 
dedicatedRowNumber() - Method in class com.palantir.atlasdb.keyvalue.api.TargetedSweepMetadata
 
DEFAULT - com.palantir.atlasdb.transaction.api.Transaction.TransactionType
 
DEFAULT_INITIALIZE_ASYNC - Static variable in interface com.palantir.atlasdb.spi.AtlasDbFactory
 
DEFAULT_NAMESPACE - Static variable in class com.palantir.atlasdb.keyvalue.api.Namespace
 
defaultGetRangesConcurrency() - Method in class com.palantir.atlasdb.spi.DerivedSnapshotConfig
The maximum number of threads from the pool of DerivedSnapshotConfig.concurrentGetRangesThreadPoolSize() to use for a single getRanges request when the user does not explicitly provide a value.
delete(TableReference, Multimap<Cell, Long>) - Method in interface com.palantir.atlasdb.keyvalue.api.KeyValueService
Deletes values from the key-value store.
delete(TableReference, Set<Cell>) - Method in class com.palantir.atlasdb.keyvalue.api.cache.NoOpTransactionScopedCache
 
delete(TableReference, Set<Cell>) - Method in class com.palantir.atlasdb.keyvalue.api.cache.ReadOnlyTransactionScopedCache
 
delete(TableReference, Set<Cell>) - Method in interface com.palantir.atlasdb.keyvalue.api.cache.TransactionScopedCache
 
delete(TableReference, Set<Cell>) - Method in interface com.palantir.atlasdb.transaction.api.Transaction
Deletes values from the key-value store.
deleteAllTimestamps(TableReference, Map<Cell, TimestampRangeDelete>) - Method in interface com.palantir.atlasdb.keyvalue.api.KeyValueService
For each cell, deletes all timestamps prior to the associated maximum timestamp.
deleteRange(TableReference, RangeRequest) - Method in interface com.palantir.atlasdb.keyvalue.api.KeyValueService
Deletes values in a range from the key-value store.
deleteRows(TableReference, Iterable<byte[]>) - Method in interface com.palantir.atlasdb.keyvalue.api.KeyValueService
Deletes multiple complete rows from the key-value store.
deleteSentinels() - Method in interface com.palantir.atlasdb.keyvalue.api.TimestampRangeDelete
 
deregisterMetrics() - Method in class com.palantir.atlasdb.util.MetricsManager
 
deregisterTaggedMetrics(Predicate<MetricName>) - Method in class com.palantir.atlasdb.util.MetricsManager
 
DerivedSnapshotConfig - Class in com.palantir.atlasdb.spi
Cassandra derives the default concurrentGetRangesThreadPoolSize from the pool size and the number of thrift hosts.
DerivedSnapshotConfig() - Constructor for class com.palantir.atlasdb.spi.DerivedSnapshotConfig
 
disableReadWriteConflictChecking(TableReference) - Method in interface com.palantir.atlasdb.transaction.api.Transaction
Disables read-write conflict checking for this table for the duration of this transaction only.
DisjointUnionTaggedMetricSet - Class in com.palantir.atlasdb.metrics
Combines two TaggedMetricSets.
DisjointUnionTaggedMetricSet(TaggedMetricSet, TaggedMetricSet) - Constructor for class com.palantir.atlasdb.metrics.DisjointUnionTaggedMetricSet
 
doNotPublish(MetricName) - Method in class com.palantir.atlasdb.util.MetricsManager
 
dropStoreSpace(PersistentStore.Handle) - Method in interface com.palantir.atlasdb.persistent.api.PersistentStore
Drops the store space specified by the supplied handle.
dropTable(TableReference) - Method in interface com.palantir.atlasdb.keyvalue.api.KeyValueService
Drop the table, and also delete its table metadata.
dropTables(Set<TableReference>) - Method in interface com.palantir.atlasdb.keyvalue.api.KeyValueService
Drops many tables in idempotent fashion.

E

empty() - Static method in class com.palantir.atlasdb.keyvalue.api.cache.CacheValue
 
EMPTY_BYTE_ARRAY - Static variable in class com.palantir.atlasdb.encoding.PtBytes
 
EMPTY_NAMESPACE - Static variable in class com.palantir.atlasdb.keyvalue.api.Namespace
 
encodeBase64String(byte[]) - Static method in class com.palantir.atlasdb.encoding.PtBytes
 
encodeBase64String(byte[], int, int) - Static method in class com.palantir.atlasdb.encoding.PtBytes
 
encodeHexString(byte[]) - Static method in class com.palantir.atlasdb.encoding.PtBytes
 
endInclusive() - Method in interface com.palantir.atlasdb.keyvalue.api.TimestampRangeDelete
 
endRowExclusive(byte[]) - Method in class com.palantir.atlasdb.keyvalue.api.RangeRequest.Builder
 
endRowExclusive(Prefix) - Method in class com.palantir.atlasdb.keyvalue.api.RangeRequest.Builder
 
endRowExclusive(Persistable) - Method in class com.palantir.atlasdb.keyvalue.api.RangeRequest.Builder
 
endRowExclusiveOrOneAfterMax(RangeRequest) - Static method in class com.palantir.atlasdb.keyvalue.api.RangeRequests
This is a replacement for endRow when doing a non-reverse range request.
ensureStateRemoved(long) - Method in interface com.palantir.atlasdb.keyvalue.api.cache.LockWatchValueScopingCache
Guarantees that all relevant state for the given transaction has been removed.
ensureVersionReported() - Static method in class com.palantir.atlasdb.versions.AtlasDbVersion
 
ensureVersionReported(PrintStream) - Static method in class com.palantir.atlasdb.versions.AtlasDbVersion
 
entireTable(TableReference) - Static method in class com.palantir.atlasdb.keyvalue.api.watch.LockWatchReferenceUtils
 
equals(Object) - Method in class com.palantir.atlasdb.keyvalue.api.BatchColumnRangeSelection
 
equals(Object) - Method in class com.palantir.atlasdb.keyvalue.api.cache.CacheValue
 
equals(Object) - Method in class com.palantir.atlasdb.keyvalue.api.Cell
 
equals(Object) - Method in class com.palantir.atlasdb.keyvalue.api.ColumnRangeSelection
 
equals(Object) - Method in class com.palantir.atlasdb.keyvalue.api.ColumnSelection
 
equals(Object) - Method in class com.palantir.atlasdb.keyvalue.api.Namespace
 
equals(Object) - Method in class com.palantir.atlasdb.keyvalue.api.RangeRequest
 
equals(Object) - Method in class com.palantir.atlasdb.keyvalue.api.RowResult
 
equals(Object) - Method in class com.palantir.atlasdb.keyvalue.api.TableReference
 
equals(Object) - Method in class com.palantir.atlasdb.keyvalue.api.Value
 
equals(Object) - Method in interface com.palantir.atlasdb.transaction.service.TransactionStatus
 
exactCell(TableReference, Cell) - Static method in class com.palantir.atlasdb.keyvalue.api.watch.LockWatchReferenceUtils
 
exactRow(TableReference, byte[]) - Static method in class com.palantir.atlasdb.keyvalue.api.watch.LockWatchReferenceUtils
 
execute(Transaction) - Method in interface com.palantir.atlasdb.transaction.api.RuntimeTransactionTask
 
execute(Transaction) - Method in interface com.palantir.atlasdb.transaction.api.TransactionTask
 
execute(Transaction, C) - Method in interface com.palantir.atlasdb.transaction.api.ConditionAwareTransactionTask
 
execute(Transaction, Iterable<HeldLocksToken>) - Method in interface com.palantir.atlasdb.transaction.api.LockAwareTransactionTask
 
expected() - Method in interface com.palantir.atlasdb.keyvalue.api.MultiCheckAndSetRequest
 
extractColumnSelection(RangeRequest) - Static method in class com.palantir.atlasdb.keyvalue.api.RangeRequests
 

F

FilteredTaggedMetricSet - Class in com.palantir.atlasdb.metrics
 
FilteredTaggedMetricSet(TaggedMetricSet, Predicate<MetricName>, Refreshable<Boolean>) - Constructor for class com.palantir.atlasdb.metrics.FilteredTaggedMetricSet
 
finalise() - Method in class com.palantir.atlasdb.keyvalue.api.cache.NoOpTransactionScopedCache
 
finalise() - Method in class com.palantir.atlasdb.keyvalue.api.cache.ReadOnlyTransactionScopedCache
 
finalise() - Method in interface com.palantir.atlasdb.keyvalue.api.cache.TransactionScopedCache
This method should be called before retrieving the value or hit digest, as it guarantees that no more reads or writes will be performed on the cache.
findConstraintFailures(Map<Cell, byte[]>, ConstraintCheckingTransaction, AtlasDbConstraintCheckingMode) - Method in interface com.palantir.atlasdb.transaction.api.ConstraintCheckable
This method checks row, table, and foreign-key constraints on the values given in writes.
findConstraintFailuresNoRead(Map<Cell, byte[]>, AtlasDbConstraintCheckingMode) - Method in interface com.palantir.atlasdb.transaction.api.ConstraintCheckable
Calling this method will not cause any read calls from the database.
finish(TransactionTask<T, E>) - Method in interface com.palantir.atlasdb.transaction.api.OpenTransaction
Runs a provided task, commits the transaction, and performs cleanup.
finishWithCallback(TransactionTask<T, E>, Runnable) - Method in interface com.palantir.atlasdb.transaction.api.OpenTransaction
Like OpenTransaction.finish(TransactionTask), except runs a callback after the task has finished.
forEachMetric(BiConsumer<MetricName, Metric>) - Method in class com.palantir.atlasdb.metrics.DisjointUnionTaggedMetricSet
 
forEachMetric(BiConsumer<MetricName, Metric>) - Method in class com.palantir.atlasdb.metrics.FilteredTaggedMetricSet
 
fromBoolean(boolean) - Static method in enum com.palantir.atlasdb.config.LockLeader
 
fromInternalTableName(String) - Static method in class com.palantir.atlasdb.keyvalue.api.TableReference
Deprecated.
uses TableReference.createUnsafe(java.lang.String), which is itself deprecated.
fromString(String) - Static method in class com.palantir.atlasdb.keyvalue.api.TableReference
 
FULL_CONSTRAINT_CHECKING_LOGS_EXCEPTIONS - com.palantir.atlasdb.transaction.api.AtlasDbConstraintCheckingMode
 
FULL_CONSTRAINT_CHECKING_THROWS_EXCEPTIONS - com.palantir.atlasdb.transaction.api.AtlasDbConstraintCheckingMode
 

G

get(long) - Method in interface com.palantir.atlasdb.transaction.service.TransactionService
Gets the commit timestamp associated with a given start timestamp.
get(TableReference, Map<Cell, Long>) - Method in interface com.palantir.atlasdb.keyvalue.api.KeyValueService
Gets values from the key-value store.
get(TableReference, Set<Cell>) - Method in interface com.palantir.atlasdb.transaction.api.Transaction
Gets the values associated for each cell in cells from table specified by tableRef.
get(TableReference, Set<Cell>, Function<Set<Cell>, ListenableFuture<Map<Cell, byte[]>>>) - Method in class com.palantir.atlasdb.keyvalue.api.cache.NoOpTransactionScopedCache
 
get(TableReference, Set<Cell>, Function<Set<Cell>, ListenableFuture<Map<Cell, byte[]>>>) - Method in class com.palantir.atlasdb.keyvalue.api.cache.ReadOnlyTransactionScopedCache
 
get(TableReference, Set<Cell>, Function<Set<Cell>, ListenableFuture<Map<Cell, byte[]>>>) - Method in interface com.palantir.atlasdb.keyvalue.api.cache.TransactionScopedCache
This should be used for performing *synchronous* gets.
get(PersistentStore.Handle, ByteString) - Method in interface com.palantir.atlasdb.persistent.api.PersistentStore
Gets the value associated with the entry specified by key.
get(PersistentStore.Handle, List<ByteString>) - Method in interface com.palantir.atlasdb.persistent.api.PersistentStore
Gets the values associated with the entries specified by keys.
get(Iterable<Long>) - Method in interface com.palantir.atlasdb.transaction.service.TransactionService
 
GET_TIMESTAMP - Static variable in class com.palantir.atlasdb.keyvalue.api.Value
 
GET_VALUE - Static variable in class com.palantir.atlasdb.keyvalue.api.Value
 
getActualValues() - Method in exception com.palantir.atlasdb.keyvalue.api.CheckAndSetException
 
getActualValues() - Method in exception com.palantir.atlasdb.keyvalue.api.MultiCheckAndSetException
 
getAllTableNames() - Method in interface com.palantir.atlasdb.keyvalue.api.KeyValueService
Return the list of tables stored in this key value service.
getAllTimestamps(TableReference, Set<Cell>, long) - Method in interface com.palantir.atlasdb.keyvalue.api.KeyValueService
Gets timestamp values from the key-value store.
getArgs() - Method in exception com.palantir.atlasdb.keyvalue.api.RetryLimitReachedException
 
getAsync(long) - Method in interface com.palantir.atlasdb.transaction.service.AsyncTransactionService
Gets the commit timestamp associated with a given startTimestamp in a future, potentially computing it asynchronously.
getAsync(TableReference, Map<Cell, Long>) - Method in interface com.palantir.atlasdb.keyvalue.api.AsyncKeyValueService
Asynchronously gets values from the key-value store when the store allows it.
getAsync(TableReference, Set<Cell>) - Method in interface com.palantir.atlasdb.transaction.api.Transaction
Gets the values associated for each cell in cells from table specified by tableRef.
getAsync(TableReference, Set<Cell>, Function<Set<Cell>, ListenableFuture<Map<Cell, byte[]>>>) - Method in class com.palantir.atlasdb.keyvalue.api.cache.NoOpTransactionScopedCache
 
getAsync(TableReference, Set<Cell>, Function<Set<Cell>, ListenableFuture<Map<Cell, byte[]>>>) - Method in class com.palantir.atlasdb.keyvalue.api.cache.ReadOnlyTransactionScopedCache
 
getAsync(TableReference, Set<Cell>, Function<Set<Cell>, ListenableFuture<Map<Cell, byte[]>>>) - Method in interface com.palantir.atlasdb.keyvalue.api.cache.TransactionScopedCache
 
getAsync(Iterable<Long>) - Method in interface com.palantir.atlasdb.transaction.service.AsyncTransactionService
Gets the commit timestamps associated with start timestamps given in startTimestamps, potentially computing them asynchronously.
getBatchHint() - Method in class com.palantir.atlasdb.keyvalue.api.BatchColumnRangeSelection
 
getBatchHint() - Method in class com.palantir.atlasdb.keyvalue.api.RangeRequest
 
getBuilder() - Method in class com.palantir.atlasdb.keyvalue.api.RangeRequest
 
getBytes() - Method in class com.palantir.atlasdb.keyvalue.api.Prefix
 
getCache() - Method in class com.palantir.atlasdb.keyvalue.api.watch.LockWatchManagerInternal
 
getCache() - Method in class com.palantir.atlasdb.keyvalue.api.watch.NoOpLockWatchManager
 
getCached(TableReference, Set<Cell>) - Method in interface com.palantir.atlasdb.transaction.api.LockWatchingCache
Given a table and a set of cells, the cache returns a map containing the latest cached GuardedValues for cells present in the cache.
getCached(TableReference, Set<Cell>) - Method in class com.palantir.atlasdb.transaction.api.NoOpLockWatchingCache
 
getCandidateCellsForSweeping(TableReference, CandidateCellForSweepingRequest) - Method in interface com.palantir.atlasdb.keyvalue.api.KeyValueService
For a given range of rows, returns all candidate cells for sweeping (and their timestamps).
getCell() - Method in class com.palantir.atlasdb.transaction.api.TransactionConflictException.CellConflict
 
getCellFunction() - Static method in class com.palantir.atlasdb.transaction.api.TransactionConflictException.CellConflict
 
getCells() - Method in class com.palantir.atlasdb.keyvalue.api.RowResult
 
getCellSet() - Method in class com.palantir.atlasdb.keyvalue.api.RowResult
 
getCellTsPairsExamined() - Method in class com.palantir.atlasdb.keyvalue.api.SweepResults
The approximate number of (cell, timestamp) pairs examined.
getCheckAndSetCompatibility() - Method in interface com.palantir.atlasdb.keyvalue.api.KeyValueService
Get the CheckAndSetCompatibility that this KeyValueService exhibits.
getCleaner() - Method in interface com.palantir.atlasdb.transaction.api.TransactionManager
Returns the cleaner used by this transaction manager.
getClusterAvailabilityStatus() - Method in interface com.palantir.atlasdb.keyvalue.api.KeyValueService
Provides a ClusterAvailabilityStatus, indicating the current availability of the key value store.
getColumnName() - Method in class com.palantir.atlasdb.keyvalue.api.Cell
The name of the column within the row.
getColumnNames() - Method in class com.palantir.atlasdb.keyvalue.api.RangeRequest
An empty set of column names means that all columns are selected.
getColumns() - Method in class com.palantir.atlasdb.keyvalue.api.RowResult
 
getConflictingTable() - Method in exception com.palantir.atlasdb.transaction.api.TransactionConflictException
 
getConflictingTable() - Method in exception com.palantir.atlasdb.transaction.api.TransactionSerializableConflictException
 
getContents() - Method in class com.palantir.atlasdb.keyvalue.api.Value
The contents of the value.
getDelegates() - Method in interface com.palantir.atlasdb.keyvalue.api.KeyValueService
Gets all key value services this key value service delegates to directly.
getDominatingWrites() - Method in exception com.palantir.atlasdb.transaction.api.TransactionConflictException
These conflicts started and committed after our start timestamp.
getEndCol() - Method in class com.palantir.atlasdb.keyvalue.api.BatchColumnRangeSelection
 
getEndCol() - Method in class com.palantir.atlasdb.keyvalue.api.ColumnRangeSelection
 
getEndExclusive() - Method in class com.palantir.atlasdb.keyvalue.api.RangeRequest
End is exclusive.
getExistingKeys() - Method in exception com.palantir.atlasdb.keyvalue.api.KeyAlreadyExistsException
 
getExpectedValue() - Method in exception com.palantir.atlasdb.keyvalue.api.CheckAndSetException
 
getExpectedValues() - Method in exception com.palantir.atlasdb.keyvalue.api.MultiCheckAndSetException
 
getFirstBatchForRanges(TableReference, Iterable<RangeRequest>, long) - Method in interface com.palantir.atlasdb.keyvalue.api.KeyValueService
For each range passed in the result will have the first page of results for that range.
getFirstRowName() - Static method in class com.palantir.atlasdb.keyvalue.api.RangeRequests
 
getHitDigest() - Method in class com.palantir.atlasdb.keyvalue.api.cache.NoOpTransactionScopedCache
 
getHitDigest() - Method in class com.palantir.atlasdb.keyvalue.api.cache.ReadOnlyTransactionScopedCache
 
getHitDigest() - Method in interface com.palantir.atlasdb.keyvalue.api.cache.TransactionScopedCache
 
getIgnoringLocalWrites(TableReference, Set<Cell>) - Method in interface com.palantir.atlasdb.transaction.api.ConstraintCheckingTransaction
Returns the cell values in the key-value service, ignoring the cache of local writes.
getImmutableTimestamp() - Method in interface com.palantir.atlasdb.transaction.api.TransactionManager
Most AtlasDB TransactionManagers will provide Transaction objects that have less than full serializability.
getKey() - Method in exception com.palantir.atlasdb.keyvalue.api.CheckAndSetException
 
getKeyValueService() - Method in interface com.palantir.atlasdb.transaction.api.TransactionManager
Returns the KVS used by this transaction manager.
getKeyValueServiceStatus() - Method in interface com.palantir.atlasdb.transaction.api.TransactionManager
Provides a KeyValueServiceStatus, indicating the current availability of the key value store.
getKnownSeries() - Method in interface com.palantir.atlasdb.keyvalue.api.TimestampSeriesProvider
 
getKnownSuccessfullyCommittedKeys() - Method in exception com.palantir.atlasdb.keyvalue.api.KeyAlreadyExistsException
 
getLabel() - Method in interface com.palantir.atlasdb.metrics.MetricPublicationFilter
A label which is used to deduplicate filters; it need only be unique across filters on a given metric.
getLastColumnName() - Static method in class com.palantir.atlasdb.keyvalue.api.RangeRequests
 
getLastRowName() - Static method in class com.palantir.atlasdb.keyvalue.api.RangeRequests
 
getLatestTimestamps(TableReference, Map<Cell, Long>) - Method in interface com.palantir.atlasdb.keyvalue.api.KeyValueService
Gets timestamp values from the key-value store.
getLockService() - Method in interface com.palantir.atlasdb.transaction.api.TransactionManager
Returns the lock service used by this transaction manager.
getLockWatchManager() - Method in interface com.palantir.atlasdb.transaction.api.TransactionManager
 
getLogMessage() - Method in exception com.palantir.atlasdb.keyvalue.api.RetryLimitReachedException
 
getMetadataForTable(TableReference) - Method in interface com.palantir.atlasdb.keyvalue.api.KeyValueService
Gets the metadata for a given table.
getMetadataForTables() - Method in interface com.palantir.atlasdb.keyvalue.api.KeyValueService
Gets the metadata for all known user-created Atlas tables.
getMetrics() - Method in class com.palantir.atlasdb.metrics.DisjointUnionTaggedMetricSet
 
getMetrics() - Method in class com.palantir.atlasdb.metrics.FilteredTaggedMetricSet
 
getMinSweptTimestamp() - Method in class com.palantir.atlasdb.keyvalue.api.SweepResults
The minimum sweep timestamp while sweeping this table.
getName() - Method in class com.palantir.atlasdb.keyvalue.api.Namespace
 
getNamespace() - Method in class com.palantir.atlasdb.keyvalue.api.TableReference
 
getNextStartRow() - Method in class com.palantir.atlasdb.keyvalue.api.SweepResults
 
getNextStartRow(boolean, byte[]) - Static method in class com.palantir.atlasdb.keyvalue.api.RangeRequests
 
getNextStartRowNullable() - Method in class com.palantir.atlasdb.keyvalue.api.SweepResults
 
getNextStartRowUnlessTerminal(boolean, byte[]) - Static method in class com.palantir.atlasdb.keyvalue.api.RangeRequests
 
getOnlyColumnValue() - Method in class com.palantir.atlasdb.keyvalue.api.RowResult
 
getOrderingByRowName() - Static method in class com.palantir.atlasdb.keyvalue.api.RowResult
 
getOrderingByRowName(boolean) - Static method in class com.palantir.atlasdb.keyvalue.api.RowResult
 
getPersistingClassType() - Method in interface com.palantir.atlasdb.persist.api.Persister
Deprecated.
 
getPersistingClassType() - Method in interface com.palantir.atlasdb.persist.api.ReusablePersister
 
getPreviousStartRow() - Method in class com.palantir.atlasdb.keyvalue.api.SweepResults
 
getPreviousStartRowNullable() - Method in class com.palantir.atlasdb.keyvalue.api.SweepResults
 
getPublishableMetrics() - Method in class com.palantir.atlasdb.util.MetricsManager
 
getQualifiedName() - Method in class com.palantir.atlasdb.keyvalue.api.TableReference
 
getRange(TableReference, RangeRequest) - Method in interface com.palantir.atlasdb.transaction.api.Transaction
Creates a visitable that scans the provided range.
getRange(TableReference, RangeRequest, long) - Method in interface com.palantir.atlasdb.keyvalue.api.KeyValueService
For each row in the specified range, returns the most recent version strictly before timestamp.
getRangeOfTimestamps(TableReference, RangeRequest, long) - Method in interface com.palantir.atlasdb.keyvalue.api.KeyValueService
getRanges(TableReference, Iterable<RangeRequest>) - Method in interface com.palantir.atlasdb.transaction.api.Transaction
Deprecated.
Should use either Transaction.getRanges(TableReference, Iterable, int, BiFunction) or Transaction.getRangesLazy(TableReference, Iterable) to ensure you are using an appropriate level of concurrency for your specific workflow.
getRanges(TableReference, Iterable<RangeRequest>, int, BiFunction<RangeRequest, BatchingVisitable<RowResult<byte[]>>, T>) - Method in interface com.palantir.atlasdb.transaction.api.Transaction
Creates unvisited visitables that scan the provided ranges and then applies the provided visitableProcessor function with concurrency specified by the concurrencyLevel parameter.
getRanges(TableReference, Iterable<RangeRequest>, BiFunction<RangeRequest, BatchingVisitable<RowResult<byte[]>>, T>) - Method in interface com.palantir.atlasdb.transaction.api.Transaction
Same as Transaction.getRanges(TableReference, Iterable, int, BiFunction) but uses the default concurrency value specified by KeyValueServiceConfig#defaultGetRangesConcurrency().
getRanges(GetRangesQuery<T>) - Method in interface com.palantir.atlasdb.transaction.api.Transaction
getRangesLazy(TableReference, Iterable<RangeRequest>) - Method in interface com.palantir.atlasdb.transaction.api.Transaction
Returns visitibles that scan the provided ranges.
GetRangesQuery<RESPONSE_TYPE> - Interface in com.palantir.atlasdb.transaction.api
 
getReadOnlyTransactionScopedCache(long) - Method in class com.palantir.atlasdb.keyvalue.api.watch.LockWatchManagerInternal
 
getReadOnlyTransactionScopedCache(long) - Method in class com.palantir.atlasdb.keyvalue.api.watch.NoOpLockWatchManager
 
getReadOnlyTransactionScopedCacheForCommit(long) - Method in interface com.palantir.atlasdb.keyvalue.api.cache.LockWatchValueScopingCache
Returns a read-only view of the transaction cache at commit time (specifically, **after** getting the commit timestamp, but before ending the transaction).
getReadSentinelBehavior() - Method in interface com.palantir.atlasdb.transaction.api.Transaction
Determines what the transaction should do if it reads a sentinel timestamp which indicates it may be performing an inconsistent read.
getRegistry() - Method in class com.palantir.atlasdb.util.MetricsManager
 
getRowKeysInRange(TableReference, byte[], byte[], int) - Method in interface com.palantir.atlasdb.keyvalue.api.KeyValueService
Deprecated.
if you wish to use this method, contact the atlasdb team for support
getRowName() - Method in class com.palantir.atlasdb.keyvalue.api.Cell
The name of the row within the table.
getRowName() - Method in exception com.palantir.atlasdb.keyvalue.api.MultiCheckAndSetException
 
getRowName() - Method in class com.palantir.atlasdb.keyvalue.api.RowResult
 
getRowNameFun() - Static method in class com.palantir.atlasdb.keyvalue.api.RowResult
 
getRows(TableReference, Iterable<byte[]>, ColumnSelection) - Method in interface com.palantir.atlasdb.transaction.api.Transaction
Returns a mapping of rows to RowResults within tableRef for the specified rows, loading columns according to the provided ColumnSelection.
getRows(TableReference, Iterable<byte[]>, ColumnSelection, long) - Method in interface com.palantir.atlasdb.keyvalue.api.KeyValueService
Gets values from the key-value store.
getRows(TableReference, Iterable<byte[]>, ColumnSelection, Function<Set<Cell>, Map<Cell, byte[]>>, Function<Iterable<byte[]>, NavigableMap<byte[], RowResult<byte[]>>>) - Method in class com.palantir.atlasdb.keyvalue.api.cache.NoOpTransactionScopedCache
 
getRows(TableReference, Iterable<byte[]>, ColumnSelection, Function<Set<Cell>, Map<Cell, byte[]>>, Function<Iterable<byte[]>, NavigableMap<byte[], RowResult<byte[]>>>) - Method in class com.palantir.atlasdb.keyvalue.api.cache.ReadOnlyTransactionScopedCache
 
getRows(TableReference, Iterable<byte[]>, ColumnSelection, Function<Set<Cell>, Map<Cell, byte[]>>, Function<Iterable<byte[]>, NavigableMap<byte[], RowResult<byte[]>>>) - Method in interface com.palantir.atlasdb.keyvalue.api.cache.TransactionScopedCache
The cache will try to fulfil as much of the request as possible with cached values.
getRowsColumnRange(TableReference, Iterable<byte[]>, BatchColumnRangeSelection) - Method in interface com.palantir.atlasdb.transaction.api.Transaction
Returns a mapping of requested rows to corresponding columns from the queried table.
getRowsColumnRange(TableReference, Iterable<byte[]>, BatchColumnRangeSelection, long) - Method in interface com.palantir.atlasdb.keyvalue.api.KeyValueService
Gets values from the key-value store for the specified rows and column range as separate iterators for each row.
getRowsColumnRange(TableReference, Iterable<byte[]>, ColumnRangeSelection, int) - Method in interface com.palantir.atlasdb.transaction.api.Transaction
Returns a single iterator over the cell-value pairs in tableRef for the specified rows, where the columns fall within the provided ColumnRangeSelection.
getRowsColumnRange(TableReference, Iterable<byte[]>, ColumnRangeSelection, int, long) - Method in interface com.palantir.atlasdb.keyvalue.api.KeyValueService
Gets values from the key-value store for the specified rows and column range as a single iterator.
getRowsColumnRangeIterator(TableReference, Iterable<byte[]>, BatchColumnRangeSelection) - Method in interface com.palantir.atlasdb.transaction.api.Transaction
Returns a mapping of rows to Iterators over cell-value pairs within tableRef for the specified rows, where the columns fall within the provided BatchColumnRangeSelection.
getRowsIgnoringLocalWrites(TableReference, Iterable<byte[]>) - Method in interface com.palantir.atlasdb.transaction.api.ConstraintCheckingTransaction
Returns the row result values in the key-value service, ignoring the cache of local writes.
getSelectedColumns() - Method in class com.palantir.atlasdb.keyvalue.api.ColumnSelection
 
getSortedColumns(TableReference, Iterable<byte[]>, BatchColumnRangeSelection) - Method in interface com.palantir.atlasdb.transaction.api.Transaction
Returns an iterator over cell-value pairs within tableRef for the specified rows, where the columns fall within the provided BatchColumnRangeSelection.The single provided BatchColumnRangeSelection applies to all of the rows.
getSpanningWrites() - Method in exception com.palantir.atlasdb.transaction.api.TransactionConflictException
These conflicts had a start timestamp before our start and a commit timestamp after our start.
getStaleValuesDeleted() - Method in class com.palantir.atlasdb.keyvalue.api.SweepResults
The number of (cell, timestamp) pairs deleted.
getStartCol() - Method in class com.palantir.atlasdb.keyvalue.api.BatchColumnRangeSelection
 
getStartCol() - Method in class com.palantir.atlasdb.keyvalue.api.ColumnRangeSelection
 
getStartInclusive() - Method in class com.palantir.atlasdb.keyvalue.api.RangeRequest
Start is inclusive.
getTablename() - Method in class com.palantir.atlasdb.keyvalue.api.TableReference
Deprecated.
Please use TableReference.getTableName(), which is consistent with broader AtlasDB naming conventions.
getTableName() - Method in class com.palantir.atlasdb.keyvalue.api.TableReference
 
getTableNameTagFor(TableReference) - Method in class com.palantir.atlasdb.util.MetricsManager
 
getTaggedRegistry() - Method in class com.palantir.atlasdb.util.MetricsManager
 
getTheirStart() - Method in class com.palantir.atlasdb.transaction.api.TransactionConflictException.CellConflict
 
getTimeElapsedSinceStartedSweeping() - Method in class com.palantir.atlasdb.keyvalue.api.SweepResults
 
getTimeInMillis() - Method in class com.palantir.atlasdb.keyvalue.api.SweepResults
Time spent sweeping this iteration in milliseconds.
getTimelockService() - Method in interface com.palantir.atlasdb.transaction.api.TransactionManager
Returns the timelock service used by this transaction manager.
getTimelockServiceStatus() - Method in interface com.palantir.atlasdb.transaction.api.TransactionManager
Provides a TimelockServiceStatus, indicating the current availability of the timelock service.
getTimestamp() - Method in class com.palantir.atlasdb.keyvalue.api.Value
The timestamp of the value.
getTimestamp() - Method in interface com.palantir.atlasdb.transaction.api.Transaction
Gets the timestamp the current transaction is running at.
getTimestampManagementService() - Method in interface com.palantir.atlasdb.transaction.api.TransactionManager
The timestamp management service is used by libraries providing additional functionality around AtlasDB.
getTimestampService() - Method in interface com.palantir.atlasdb.transaction.api.TransactionManager
Returns the timestamp service used by this transaction manager.
getTimeSweepStarted() - Method in class com.palantir.atlasdb.keyvalue.api.SweepResults
Time in milliseconds when we started sweeping this table.
getTransactionReadTimeoutMillis() - Method in interface com.palantir.atlasdb.cleaner.api.Cleaner
Returns the timeout for transactions reads in milliseconds.
getTransactionScopedCache(long) - Method in interface com.palantir.atlasdb.keyvalue.api.cache.LockWatchValueScopingCache
 
getTransactionScopedCache(long) - Method in class com.palantir.atlasdb.keyvalue.api.watch.LockWatchManagerInternal
 
getTransactionScopedCache(long) - Method in class com.palantir.atlasdb.keyvalue.api.watch.NoOpLockWatchManager
 
getTransactionService() - Method in interface com.palantir.atlasdb.transaction.api.TransactionManager
The transaction service is used by libraries providing additional functionality around AtlasDB.
getTransactionType() - Method in interface com.palantir.atlasdb.transaction.api.Transaction
 
getType() - Method in interface com.palantir.atlasdb.spi.AtlasDbFactory
 
getType() - Method in interface com.palantir.atlasdb.timestamp.DbTimeLockFactory
 
getUnreadableTimestamp() - Method in interface com.palantir.atlasdb.cleaner.api.Cleaner
Returns the timestamp that is before any open start timestamps.
getUnreadableTimestamp() - Method in interface com.palantir.atlasdb.transaction.api.TransactionManager
Returns the timestamp that is before any open start timestamps.
getValueDigest() - Method in class com.palantir.atlasdb.keyvalue.api.cache.NoOpTransactionScopedCache
 
getValueDigest() - Method in class com.palantir.atlasdb.keyvalue.api.cache.ReadOnlyTransactionScopedCache
 
getValueDigest() - Method in interface com.palantir.atlasdb.keyvalue.api.cache.TransactionScopedCache
 
getView(long, LockWatchStateUpdate) - Method in interface com.palantir.atlasdb.transaction.api.LockWatchingCache
Creates a view of the cache for a transaction, based on the start timestamp and the lock watch state.
getView(long, LockWatchStateUpdate) - Method in class com.palantir.atlasdb.transaction.api.NoOpLockWatchingCache
 
goodHash() - Method in class com.palantir.atlasdb.keyvalue.api.CellReference
Cell.hashCode() implementation has a rather unfortunate case where it is always 0 if the row name and the column name match.
GuardedValue - Interface in com.palantir.atlasdb.transaction.api
 
guardTimestamp() - Method in interface com.palantir.atlasdb.transaction.api.GuardedValue
 

H

HARD_DELETE - com.palantir.atlasdb.transaction.api.Transaction.TransactionType
Hard delete transactions are different from regular transactions because they must queue cells for "scrubbing" on every cell that's modified or deleted.
hashCode() - Method in class com.palantir.atlasdb.keyvalue.api.BatchColumnRangeSelection
 
hashCode() - Method in class com.palantir.atlasdb.keyvalue.api.cache.CacheValue
 
hashCode() - Method in class com.palantir.atlasdb.keyvalue.api.Cell
 
hashCode() - Method in class com.palantir.atlasdb.keyvalue.api.ColumnRangeSelection
 
hashCode() - Method in class com.palantir.atlasdb.keyvalue.api.ColumnSelection
 
hashCode() - Method in class com.palantir.atlasdb.keyvalue.api.Namespace
 
hashCode() - Method in class com.palantir.atlasdb.keyvalue.api.RangeRequest
 
hashCode() - Method in class com.palantir.atlasdb.keyvalue.api.RowResult
 
hashCode() - Method in class com.palantir.atlasdb.keyvalue.api.TableReference
 
hashCode() - Method in class com.palantir.atlasdb.keyvalue.api.Value
 
head(byte[], int) - Static method in class com.palantir.atlasdb.encoding.PtBytes
 
HEALTHY - com.palantir.atlasdb.transaction.api.TimelockServiceStatus
 
HEALTHY_ALL_OPERATIONS - com.palantir.atlasdb.transaction.api.KeyValueServiceStatus
 
HEALTHY_BUT_NO_SCHEMA_MUTATIONS_OR_DELETES - com.palantir.atlasdb.transaction.api.KeyValueServiceStatus
 
hitCells() - Method in interface com.palantir.atlasdb.keyvalue.api.cache.HitDigest
 
HitDigest - Interface in com.palantir.atlasdb.keyvalue.api.cache
 

I

I_AM_THE_LOCK_LEADER - com.palantir.atlasdb.config.LockLeader
 
id() - Method in interface com.palantir.atlasdb.persistent.api.PersistentStore.Handle
 
IGNORE - com.palantir.atlasdb.transaction.api.TransactionReadSentinelBehavior
Ignore the sentinel read, and pretend that there is no value for this cell.
IGNORE_ALL - com.palantir.atlasdb.transaction.api.ConflictHandler
If two transactions concurrently write to the same cell the one that has started later will win.
INDETERMINATE - com.palantir.atlasdb.factory.TransactionManagerConsistencyResult.ConsistencyState
Indicates that we don't know whether the transaction manager is in a consistent state or not.
inProgress() - Method in interface com.palantir.atlasdb.transaction.service.TransactionStatus.Cases
For transactions on schema version >= 4, an inProgress state has been introduced.
inRange(byte[]) - Method in class com.palantir.atlasdb.keyvalue.api.RangeRequest
 
INSTANCE - com.palantir.atlasdb.keyvalue.api.CheckAndSetCompatibility.Unsupported
 
INSTANCE - Static variable in class com.palantir.atlasdb.transaction.api.NoOpLockWatchingCache
 
INSTANCE - Static variable in class com.palantir.atlasdb.transaction.api.NoOpTransactionLockWatchingCacheView
 
InsufficientConsistencyException - Exception in com.palantir.atlasdb.keyvalue.api
Thrown by a key value service when an operation could not be performed because the required consistency could not be met.
InsufficientConsistencyException(String) - Constructor for exception com.palantir.atlasdb.keyvalue.api.InsufficientConsistencyException
 
InsufficientConsistencyException(String, Throwable) - Constructor for exception com.palantir.atlasdb.keyvalue.api.InsufficientConsistencyException
 
intersect(Stream<CheckAndSetCompatibility>) - Static method in interface com.palantir.atlasdb.keyvalue.api.CheckAndSetCompatibility
 
INVALID_VALUE_TIMESTAMP - Static variable in class com.palantir.atlasdb.keyvalue.api.Value
 
isAborted() - Method in interface com.palantir.atlasdb.transaction.api.Transaction
Gets whether the transaction has been aborted.
isContiguousRange(boolean, byte[], byte[]) - Static method in class com.palantir.atlasdb.keyvalue.api.RangeRequests
 
isEmpty() - Method in class com.palantir.atlasdb.keyvalue.api.Value
 
isEmptyNamespace() - Method in class com.palantir.atlasdb.keyvalue.api.Namespace
 
isEmptyRange() - Method in class com.palantir.atlasdb.keyvalue.api.RangeRequest
 
isExactlyEmptyRange(byte[], byte[]) - Static method in class com.palantir.atlasdb.keyvalue.api.RangeRequests
 
isFirstRowName(boolean, byte[]) - Static method in class com.palantir.atlasdb.keyvalue.api.RangeRequests
 
isFirstRowName(byte[]) - Static method in class com.palantir.atlasdb.keyvalue.api.RangeRequests
 
isFullyQualifiedName() - Method in class com.palantir.atlasdb.keyvalue.api.TableReference
 
isFullyQualifiedName(String) - Static method in class com.palantir.atlasdb.keyvalue.api.TableReference
 
isHealthy() - Method in enum com.palantir.atlasdb.keyvalue.api.ClusterAvailabilityStatus
 
isHealthy() - Method in enum com.palantir.atlasdb.transaction.api.KeyValueServiceStatus
 
isHealthy() - Method in enum com.palantir.atlasdb.transaction.api.TimelockServiceStatus
 
isInitialized() - Method in interface com.palantir.atlasdb.cleaner.api.Cleaner
Used for Cleaners that can be initialized asynchronously (i.e.
isInitialized() - Method in interface com.palantir.atlasdb.keyvalue.api.KeyValueService
Returns true iff the KeyValueService has been initialized and is ready to use.
isInitialized() - Method in interface com.palantir.atlasdb.transaction.api.TransactionManager
Whether this transaction manager has established a connection to the backing store and timestamp/lock services, and is ready to service transactions.
isInvalidRange() - Method in class com.palantir.atlasdb.keyvalue.api.RangeRequest.Builder
 
isLastColumnName(byte[]) - Static method in class com.palantir.atlasdb.keyvalue.api.RangeRequests
 
isLastRowName(byte[]) - Static method in class com.palantir.atlasdb.keyvalue.api.RangeRequests
 
isLatestValueEmpty() - Method in interface com.palantir.atlasdb.keyvalue.api.CandidateCellForSweeping
If CandidateCellForSweepingRequest.shouldCheckIfLatestValueIsEmpty() was set to true, then this method returns true if and only if the value corresponding to the last entry of CandidateCellForSweeping.sortedTimestamps() is empty.
isNameValid(byte[]) - Static method in class com.palantir.atlasdb.keyvalue.api.Cell
 
isReverse() - Method in class com.palantir.atlasdb.keyvalue.api.RangeRequest.Builder
 
isReverse() - Method in class com.palantir.atlasdb.keyvalue.api.RangeRequest
 
isTerminalRow(boolean, byte[]) - Static method in class com.palantir.atlasdb.keyvalue.api.RangeRequests
 
isTombstone(byte[]) - Static method in class com.palantir.atlasdb.keyvalue.api.Value
 
isUncommitted() - Method in interface com.palantir.atlasdb.transaction.api.Transaction
Gets whether the transaction has not been committed.
isValid() - Method in interface com.palantir.atlasdb.keyvalue.api.AsyncKeyValueService
Denotes whether the AsyncKeyValueService is currently capable of handling requests.
isValid() - Method in interface com.palantir.atlasdb.keyvalue.api.KeyValueService
 
isValidRange(byte[], byte[]) - Static method in class com.palantir.atlasdb.keyvalue.api.ColumnRangeSelection
 

K

KeyAlreadyExistsException - Exception in com.palantir.atlasdb.keyvalue.api
A KeyAlreadyExistsException is thrown if an operation that conditionally updates a KeyValueService fails because some data is already present in the underlying database.
KeyAlreadyExistsException(String) - Constructor for exception com.palantir.atlasdb.keyvalue.api.KeyAlreadyExistsException
 
KeyAlreadyExistsException(String, Iterable<Cell>) - Constructor for exception com.palantir.atlasdb.keyvalue.api.KeyAlreadyExistsException
 
KeyAlreadyExistsException(String, Iterable<Cell>, Iterable<Cell>) - Constructor for exception com.palantir.atlasdb.keyvalue.api.KeyAlreadyExistsException
 
KeyAlreadyExistsException(String, Throwable) - Constructor for exception com.palantir.atlasdb.keyvalue.api.KeyAlreadyExistsException
 
KeyAlreadyExistsException(String, Throwable, Iterable<Cell>) - Constructor for exception com.palantir.atlasdb.keyvalue.api.KeyAlreadyExistsException
 
KeyValueService - Interface in com.palantir.atlasdb.keyvalue.api
A service which stores key-value pairs.
KeyValueServiceConfig - Interface in com.palantir.atlasdb.spi
Marker interface for various AtlasDb KeyValueService config objects.
KeyValueServiceConfigHelper - Interface in com.palantir.atlasdb.spi
 
KeyValueServiceRuntimeConfig - Interface in com.palantir.atlasdb.spi
Marker interface for various AtlasDb KeyValueServiceRuntime config objects.
KeyValueServiceStatus - Enum in com.palantir.atlasdb.transaction.api
 

L

leaderAddressCacheTtl() - Method in class com.palantir.atlasdb.config.LeaderConfig
 
LeaderConfig - Class in com.palantir.atlasdb.config
 
LeaderConfig() - Constructor for class com.palantir.atlasdb.config.LeaderConfig
 
leaderPingResponseWait() - Method in class com.palantir.atlasdb.config.LeaderConfig
 
LeaderRuntimeConfig - Class in com.palantir.atlasdb.config
 
LeaderRuntimeConfig() - Constructor for class com.palantir.atlasdb.config.LeaderRuntimeConfig
 
leaders() - Method in class com.palantir.atlasdb.config.LeaderConfig
 
learnerLogDir() - Method in class com.palantir.atlasdb.config.LeaderConfig
 
loadedValues() - Method in interface com.palantir.atlasdb.keyvalue.api.cache.ValueDigest
 
LocalConnectionConfig - Interface in com.palantir.atlasdb.spi
 
localServer() - Method in class com.palantir.atlasdb.config.LeaderConfig
 
LockAcquisitionException - Exception in com.palantir.atlasdb.transaction.api
 
LockAcquisitionException(String) - Constructor for exception com.palantir.atlasdb.transaction.api.LockAcquisitionException
 
LockAcquisitionException(String, Throwable) - Constructor for exception com.palantir.atlasdb.transaction.api.LockAcquisitionException
 
LockAcquisitionException(Throwable) - Constructor for exception com.palantir.atlasdb.transaction.api.LockAcquisitionException
 
LockAwareTransactionTask<T,​E extends Exception> - Interface in com.palantir.atlasdb.transaction.api
 
LockAwareTransactionTasks - Class in com.palantir.atlasdb.transaction.api
 
lockCellsForConflicts() - Method in enum com.palantir.atlasdb.transaction.api.ConflictHandler
 
LockLeader - Enum in com.palantir.atlasdb.config
 
lockRowsForConflicts() - Method in enum com.palantir.atlasdb.transaction.api.ConflictHandler
 
LockWatchingCache - Interface in com.palantir.atlasdb.transaction.api
 
LockWatchManager - Class in com.palantir.atlasdb.keyvalue.api.watch
 
LockWatchManager() - Constructor for class com.palantir.atlasdb.keyvalue.api.watch.LockWatchManager
 
LockWatchManagerInternal - Class in com.palantir.atlasdb.keyvalue.api.watch
 
LockWatchManagerInternal() - Constructor for class com.palantir.atlasdb.keyvalue.api.watch.LockWatchManagerInternal
 
LockWatchReferenceUtils - Class in com.palantir.atlasdb.keyvalue.api.watch
 
LockWatchValueScopingCache - Interface in com.palantir.atlasdb.keyvalue.api.cache
The idea here is to keep a map of CellReference -> value for each table.
log - Static variable in interface com.palantir.atlasdb.spi.AtlasDbFactory
 
LOOSELY_CHECKED_NAME - Static variable in class com.palantir.atlasdb.keyvalue.api.Namespace
Less restrictive name pattern (letters, numbers, underscores, and hyphens).

M

markInProgress(long) - Method in interface com.palantir.atlasdb.transaction.service.TransactionService
In practice, a transaction on schema version >= 4 must call this method before any information about its start timestamp is persisted into the KVS; i.e.
markInProgress(Iterable<Long>) - Method in interface com.palantir.atlasdb.transaction.service.TransactionService
 
markTableInvolved(TableReference) - Method in interface com.palantir.atlasdb.transaction.api.Transaction
Marks this table as involved in this transaction, without actually reading any rows.
match(TransactionStatus.Cases<R>) - Method in interface com.palantir.atlasdb.transaction.service.TransactionStatus
 
MAX_DEDICATED_ROWS - Static variable in class com.palantir.atlasdb.keyvalue.api.TargetedSweepMetadata
 
MAX_NAME_LENGTH - Static variable in class com.palantir.atlasdb.keyvalue.api.Cell
 
MAX_SHARDS - Static variable in class com.palantir.atlasdb.keyvalue.api.TargetedSweepMetadata
 
maxTimestampExclusive() - Method in interface com.palantir.atlasdb.keyvalue.api.CandidateCellForSweepingRequest
The maximum timestamp to be returned in the resulting CandidateCellForSweeping objects.
maxTimestampToDelete() - Method in interface com.palantir.atlasdb.keyvalue.api.TimestampRangeDelete
 
maybeCacheCommittedWrites(TableReference, Map<Cell, byte[]>) - Method in interface com.palantir.atlasdb.transaction.api.LockWatchingCache
After a transaction has committed, this notifies the cache that the writes can be cached, if desired.
maybeCacheCommittedWrites(TableReference, Map<Cell, byte[]>) - Method in class com.palantir.atlasdb.transaction.api.NoOpLockWatchingCache
 
maybeCacheEntriesRead(TableReference, Map<Cell, byte[]>, LockWatchStateUpdate) - Method in interface com.palantir.atlasdb.transaction.api.LockWatchingCache
A transaction can attempt to cache entries read during the transaction using this method.
maybeCacheEntriesRead(TableReference, Map<Cell, byte[]>, LockWatchStateUpdate) - Method in class com.palantir.atlasdb.transaction.api.NoOpLockWatchingCache
 
MetricPublicationArbiter - Class in com.palantir.atlasdb.metrics
Indicates whether metrics should be published.
MetricPublicationFilter - Interface in com.palantir.atlasdb.metrics
Determines whether a metric should be published.
MetricsManager - Class in com.palantir.atlasdb.util
 
MetricsManager(MetricRegistry, TaggedMetricRegistry, Refreshable<Boolean>, Predicate<TableReference>) - Constructor for class com.palantir.atlasdb.util.MetricsManager
 
MetricsManager(MetricRegistry, TaggedMetricRegistry, Predicate<TableReference>) - Constructor for class com.palantir.atlasdb.util.MetricsManager
 
minTimestampToDelete() - Method in interface com.palantir.atlasdb.keyvalue.api.TimestampRangeDelete
 
multiCheckAndSet(MultiCheckAndSetRequest) - Method in interface com.palantir.atlasdb.keyvalue.api.KeyValueService
Performs a check-and-set for multiple cells in a row into the key-value store.
MultiCheckAndSetException - Exception in com.palantir.atlasdb.keyvalue.api
 
MultiCheckAndSetException(Arg<String>, byte[], Map<Cell, byte[]>, Map<Cell, byte[]>) - Constructor for exception com.palantir.atlasdb.keyvalue.api.MultiCheckAndSetException
 
MultiCheckAndSetRequest - Interface in com.palantir.atlasdb.keyvalue.api
A request to be supplied to KeyValueService.mulitCheckAndSet.
multipleCells(TableReference, byte[], Map<Cell, byte[]>, Map<Cell, byte[]>) - Static method in interface com.palantir.atlasdb.keyvalue.api.MultiCheckAndSetRequest
 
multiPut(Map<TableReference, ? extends Map<Cell, byte[]>>, long) - Method in interface com.palantir.atlasdb.keyvalue.api.KeyValueService
Puts values into the key-value store.

N

namespace() - Method in interface com.palantir.atlasdb.spi.KeyValueServiceConfig
 
namespace() - Method in interface com.palantir.atlasdb.spi.KeyValueServiceConfigHelper
 
Namespace - Class in com.palantir.atlasdb.keyvalue.api
 
NEVER_PUBLISH - Static variable in interface com.palantir.atlasdb.metrics.MetricPublicationFilter
 
newCell(TableReference, Cell, byte[]) - Static method in class com.palantir.atlasdb.keyvalue.api.CheckAndSetRequest
 
newCells(TableReference, byte[], Map<Cell, byte[]>) - Static method in interface com.palantir.atlasdb.keyvalue.api.MultiCheckAndSetRequest
 
newHandle() - Static method in interface com.palantir.atlasdb.persistent.api.PersistentStore.Handle
 
newValue() - Method in class com.palantir.atlasdb.keyvalue.api.CheckAndSetRequest
 
nextLexicographicName(byte[]) - Static method in class com.palantir.atlasdb.keyvalue.api.RangeRequests
 
nextStartRow(Optional<byte[]>) - Method in class com.palantir.atlasdb.keyvalue.api.SweepResults.Builder
 
NO_CONSTRAINT_CHECKING - com.palantir.atlasdb.transaction.api.AtlasDbConstraintCheckingMode
 
NO_OP_FAST_FORWARD_TIMESTAMP - Static variable in interface com.palantir.atlasdb.spi.AtlasDbFactory
 
NO_QUORUM_AVAILABLE - com.palantir.atlasdb.keyvalue.api.ClusterAvailabilityStatus
 
noColumnsSelected() - Method in class com.palantir.atlasdb.keyvalue.api.ColumnSelection
Returns true if no columns are selected.
NoOpLockWatchingCache - Class in com.palantir.atlasdb.transaction.api
 
NoOpLockWatchManager - Class in com.palantir.atlasdb.keyvalue.api.watch
 
NoOpTransactionLockWatchingCacheView - Class in com.palantir.atlasdb.transaction.api
 
NoOpTransactionScopedCache - Class in com.palantir.atlasdb.keyvalue.api.cache
 

O

of(byte[]) - Static method in class com.palantir.atlasdb.keyvalue.api.cache.CacheValue
 
of(byte[], long) - Static method in interface com.palantir.atlasdb.transaction.api.GuardedValue
 
of(Cell, T) - Static method in class com.palantir.atlasdb.keyvalue.api.RowResult
 
of(TableReference, byte[]) - Static method in interface com.palantir.atlasdb.transaction.api.RowReference
 
of(TableReference, Cell) - Static method in class com.palantir.atlasdb.keyvalue.api.CellReference
 
of(TableReference, TimestampSeries) - Static method in interface com.palantir.atlasdb.config.DbTimestampCreationSetting
 
of(String) - Static method in interface com.palantir.atlasdb.keyvalue.api.TimestampSeries
 
of(Map<CellReference, CacheValue>) - Static method in interface com.palantir.atlasdb.keyvalue.api.cache.ValueDigest
 
of(Map<LockDescriptor, RowReference>) - Static method in class com.palantir.atlasdb.transaction.api.RowLockDescriptorMapping
 
of(Set<CellReference>) - Static method in interface com.palantir.atlasdb.keyvalue.api.cache.HitDigest
 
ofSingleRow(byte[]) - Static method in class com.palantir.atlasdb.keyvalue.api.RangeRequests
 
oldValue() - Method in class com.palantir.atlasdb.keyvalue.api.CheckAndSetRequest
 
oldValue(Optional<byte[]>) - Method in class com.palantir.atlasdb.keyvalue.api.CheckAndSetRequest.Builder
 
oldValueNullable() - Method in class com.palantir.atlasdb.keyvalue.api.CheckAndSetRequest
 
OnCleanupTask - Interface in com.palantir.atlasdb.cleaner.api
This task allows us to essentially implement ON DELETE CASCADE.
oneAfterMaximumName() - Static method in class com.palantir.atlasdb.keyvalue.api.RangeRequests
 
onlyLogOnQuorumFailure() - Method in class com.palantir.atlasdb.config.LeaderRuntimeConfig
 
onSuccess(Runnable) - Method in interface com.palantir.atlasdb.transaction.api.Transaction
Registers a callback that will be called after the AtlasDB client perceives a successful commit of a transaction.
onSuccessfulCommit(long) - Method in interface com.palantir.atlasdb.keyvalue.api.cache.LockWatchValueScopingCache
Performs final cleanup for a given transaction (identified by its start timestamp).
onTransactionCommit(long) - Method in class com.palantir.atlasdb.keyvalue.api.watch.LockWatchManagerInternal
 
onTransactionCommit(long) - Method in class com.palantir.atlasdb.keyvalue.api.watch.NoOpLockWatchManager
 
OpenTransaction - Interface in com.palantir.atlasdb.transaction.api
 

P

PERFORMANCE_OPTIMAL_CONSTRAINT_CHECKING_LOGS_EXCEPTIONS - com.palantir.atlasdb.transaction.api.AtlasDbConstraintCheckingMode
 
PERFORMANCE_OPTIMAL_CONSTRAINT_CHECKING_THROWS_EXCEPTIONS - com.palantir.atlasdb.transaction.api.AtlasDbConstraintCheckingMode
 
performanceIsSensitiveToTombstones() - Method in interface com.palantir.atlasdb.keyvalue.api.KeyValueService
Whether or not read performance degrades significantly when many deleted cells are in the requested range.
PersistentStore - Interface in com.palantir.atlasdb.persistent.api
 
PersistentStore.Handle - Interface in com.palantir.atlasdb.persistent.api
Represents a handle to the underlying space of key-value pairs.
Persister<T> - Interface in com.palantir.atlasdb.persist.api
Deprecated.
Use ReusablePersister instead.
persistToBytes() - Method in class com.palantir.atlasdb.keyvalue.api.TargetedSweepMetadata
 
persistToBytes(T) - Method in interface com.palantir.atlasdb.persist.api.Persister
Deprecated.
 
persistToBytes(T) - Method in interface com.palantir.atlasdb.persist.api.ReusablePersister
 
pingRate() - Method in class com.palantir.atlasdb.config.LeaderConfig
 
poolSize() - Method in interface com.palantir.atlasdb.spi.LocalConnectionConfig
 
PreCommitCondition - Interface in com.palantir.atlasdb.transaction.api
General condition that is checked before a transaction commits for validity.
Prefix - Class in com.palantir.atlasdb.keyvalue.api
Represents a partial row to be used for range requests.
Prefix(byte[]) - Constructor for class com.palantir.atlasdb.keyvalue.api.Prefix
 
prefixRange(byte[]) - Method in class com.palantir.atlasdb.keyvalue.api.RangeRequest.Builder
This will set the start and the end to get all rows that have a given prefix.
previousLexicographicName(byte[]) - Static method in class com.palantir.atlasdb.keyvalue.api.RangeRequests
This will return the first byte[] less than the given byte[] lexicographically.
previousStartRow(Optional<byte[]>) - Method in class com.palantir.atlasdb.keyvalue.api.SweepResults.Builder
 
processStartTransactions(Set<Long>) - Method in interface com.palantir.atlasdb.keyvalue.api.cache.LockWatchValueScopingCache
 
PtBytes - Class in com.palantir.atlasdb.encoding
 
punch(long) - Method in interface com.palantir.atlasdb.cleaner.api.Cleaner
Indicate that the given timestamp has just been created.
put(TableReference, Map<Cell, byte[]>) - Method in interface com.palantir.atlasdb.transaction.api.Transaction
Puts values into the key-value store.
put(TableReference, Map<Cell, byte[]>, long) - Method in interface com.palantir.atlasdb.keyvalue.api.KeyValueService
Puts values into the key-value store.
put(PersistentStore.Handle, ByteString, ByteString) - Method in interface com.palantir.atlasdb.persistent.api.PersistentStore
Stores the value for the associated key while overwriting the existing value in the specified store space.
put(PersistentStore.Handle, Map<ByteString, ByteString>) - Method in interface com.palantir.atlasdb.persistent.api.PersistentStore
Stores the entry pairs given in toWrite, overwriting the existing values.
putMetadataForTable(TableReference, byte[]) - Method in interface com.palantir.atlasdb.keyvalue.api.KeyValueService
 
putMetadataForTables(Map<TableReference, byte[]>) - Method in interface com.palantir.atlasdb.keyvalue.api.KeyValueService
 
putUnlessExists(long, long) - Method in interface com.palantir.atlasdb.transaction.service.TransactionService
This operation is guaranteed to be atomic and only commit the value if it hasn't already been committed.
putUnlessExists(TableReference, Map<Cell, byte[]>) - Method in interface com.palantir.atlasdb.keyvalue.api.KeyValueService
Puts values into the key-value store.
putUnlessExists(Map<Long, Long>) - Method in interface com.palantir.atlasdb.transaction.service.TransactionService
This operation seeks to commit multiple transactions; implementations may override it if this can be done more efficiently than performing individual TransactionService.putUnlessExists(long, long) operations.
putWithTimestamps(TableReference, Multimap<Cell, Value>) - Method in interface com.palantir.atlasdb.keyvalue.api.KeyValueService
Puts values into the key-value store with individually specified timestamps.

Q

queueCellsForScrubbing(Multimap<Cell, TableReference>, long) - Method in interface com.palantir.atlasdb.cleaner.api.Cleaner
Queues cells to be scrubbed.
QUORUM_AVAILABLE - com.palantir.atlasdb.keyvalue.api.ClusterAvailabilityStatus
 
quorumSize() - Method in class com.palantir.atlasdb.config.LeaderConfig
 

R

randomWaitBeforeProposingLeadership() - Method in class com.palantir.atlasdb.config.LeaderConfig
 
RangeRequest - Class in com.palantir.atlasdb.keyvalue.api
Allows you to restrict a call on the database to specific rows and columns.
RangeRequest.Builder - Class in com.palantir.atlasdb.keyvalue.api
A helper class used to construct an immutable RangeRequest instance.
rangeRequestOptimizer() - Method in interface com.palantir.atlasdb.transaction.api.GetRangesQuery
An operator invoked on each range request, to possibly improve the performance of range requests based on schema knowledge.
rangeRequests() - Method in interface com.palantir.atlasdb.transaction.api.GetRangesQuery
 
RangeRequests - Class in com.palantir.atlasdb.keyvalue.api
 
readCached(TableReference, Set<Cell>) - Method in class com.palantir.atlasdb.transaction.api.NoOpTransactionLockWatchingCacheView
 
readCached(TableReference, Set<Cell>) - Method in interface com.palantir.atlasdb.transaction.api.TransactionLockWatchingCacheView
Attempts to read the cached versions of cells.
ReadOnlyTransactionScopedCache - Class in com.palantir.atlasdb.keyvalue.api.cache
 
readVersion() - Static method in class com.palantir.atlasdb.versions.AtlasDbVersion
 
reasonForInconsistency() - Method in interface com.palantir.atlasdb.factory.TransactionManagerConsistencyResult
 
registerClosingCallback(Runnable) - Method in interface com.palantir.atlasdb.transaction.api.TransactionManager
Registers a Runnable that will be run after the transaction manager is closed.
registerMetric(Class<?>, String, Gauge<?>) - Method in class com.palantir.atlasdb.util.MetricsManager
 
registerMetricsFilter(MetricName, MetricPublicationFilter) - Method in class com.palantir.atlasdb.metrics.MetricPublicationArbiter
 
registerOrGet(Class<?>, String, Gauge<T>, Map<String, String>) - Method in class com.palantir.atlasdb.util.MetricsManager
Add a new gauge metric of the given name or get the existing gauge if it is already registered.
registerOrGetCounter(Class<?>, String) - Method in class com.palantir.atlasdb.util.MetricsManager
 
registerOrGetGauge(Class<?>, String, Supplier<M>) - Method in class com.palantir.atlasdb.util.MetricsManager
 
registerOrGetHistogram(Class<?>, String) - Method in class com.palantir.atlasdb.util.MetricsManager
 
registerOrGetHistogram(Class<?>, String, Supplier<Histogram>) - Method in class com.palantir.atlasdb.util.MetricsManager
 
registerOrGetMeter(Class<?>, String) - Method in class com.palantir.atlasdb.util.MetricsManager
 
registerOrGetMeter(Class<?>, String, String) - Method in class com.palantir.atlasdb.util.MetricsManager
 
registerOrGetTaggedCounter(Class<?>, String, Map<String, String>) - Method in class com.palantir.atlasdb.util.MetricsManager
 
registerOrGetTaggedHistogram(Class<?>, String, Map<String, String>) - Method in class com.palantir.atlasdb.util.MetricsManager
 
registerOrGetTaggedHistogram(Class<?>, String, Map<String, String>, Supplier<Histogram>) - Method in class com.palantir.atlasdb.util.MetricsManager
 
registerOrGetTaggedMeter(Class<?>, String, Map<String, String>) - Method in class com.palantir.atlasdb.util.MetricsManager
 
registerOrGetTimer(Class<?>, String) - Method in class com.palantir.atlasdb.util.MetricsManager
 
registerPreciselyWatches(Set<LockWatchReferences.LockWatchReference>) - Method in class com.palantir.atlasdb.keyvalue.api.watch.LockWatchManager
Registers precisely a set of lock watches.
registerPreciselyWatches(Set<LockWatchReferences.LockWatchReference>) - Method in class com.palantir.atlasdb.keyvalue.api.watch.NoOpLockWatchManager
 
remainder() - Method in interface com.palantir.atlasdb.keyvalue.api.AtlasLockDescriptorUtils.TableRefAndRemainder
 
removeTransactionStateFromCache(long) - Method in class com.palantir.atlasdb.keyvalue.api.watch.LockWatchManagerInternal
 
removeTransactionStateFromCache(long) - Method in class com.palantir.atlasdb.keyvalue.api.watch.NoOpLockWatchManager
 
REPORT_VERSION_DEFAULT - Static variable in class com.palantir.atlasdb.versions.AtlasDbVersion
 
REPORT_VERSION_PROPERTY - Static variable in class com.palantir.atlasdb.versions.AtlasDbVersion
 
retainColumns(ColumnSelection) - Method in class com.palantir.atlasdb.keyvalue.api.RangeRequest.Builder
 
retainColumns(Iterable<byte[]>) - Method in class com.palantir.atlasdb.keyvalue.api.RangeRequest.Builder
 
RETRY_ON_VALUE_CHANGED - com.palantir.atlasdb.transaction.api.ConflictHandler
If a transaction writes a new value to a Cell (different than the value read by that transaction), then it will throw if another concurrent transaction wrote to this cell concurrently and committed first.
RETRY_ON_WRITE_WRITE - com.palantir.atlasdb.transaction.api.ConflictHandler
If two transactions concurrently write to the same cell the one that commits later will throw a TransactionConflictException and should have details about how this happened.
RETRY_ON_WRITE_WRITE_CELL - com.palantir.atlasdb.transaction.api.ConflictHandler
Same as ConflictHandler.RETRY_ON_WRITE_WRITE, but checks for conflicts by locking cells during commit instead of locking rows.
RETRY_ON_WRITE_WRITE_MIGRATION - com.palantir.atlasdb.transaction.api.ConflictHandler
This conflict handler is analogous to SERIALIZABLE_LOCK_LEVEL_MIGRATION, but for migrating between RETRY_ON_WRITE_WRITE and RETRY_ON_WRITE_WRITE_CELL.
RetryLimitReachedException - Exception in com.palantir.atlasdb.keyvalue.api
 
RetryLimitReachedException(List<Exception>) - Constructor for exception com.palantir.atlasdb.keyvalue.api.RetryLimitReachedException
 
ReusablePersister<T> - Interface in com.palantir.atlasdb.persist.api
ReusablePersisters are required to have a no arg constructor and be thread-safe.
reverseBuilder() - Static method in class com.palantir.atlasdb.keyvalue.api.RangeRequest
 
RowColumnRangeIterator - Interface in com.palantir.atlasdb.keyvalue.api
 
RowLockDescriptorMapping - Class in com.palantir.atlasdb.transaction.api
 
RowLockDescriptorMapping() - Constructor for class com.palantir.atlasdb.transaction.api.RowLockDescriptorMapping
 
rowName() - Method in interface com.palantir.atlasdb.keyvalue.api.MultiCheckAndSetRequest
 
rowName() - Method in interface com.palantir.atlasdb.transaction.api.RowReference
 
rowPrefix(TableReference, byte[]) - Static method in class com.palantir.atlasdb.keyvalue.api.watch.LockWatchReferenceUtils
 
rowRange(TableReference, byte[], byte[]) - Static method in class com.palantir.atlasdb.keyvalue.api.watch.LockWatchReferenceUtils
 
RowReference - Interface in com.palantir.atlasdb.transaction.api
 
rowReferenceForDescriptor(LockDescriptor) - Method in class com.palantir.atlasdb.transaction.api.RowLockDescriptorMapping
 
RowResult<T> - Class in com.palantir.atlasdb.keyvalue.api
 
runTaskReadOnly(TransactionTask<T, E>) - Method in interface com.palantir.atlasdb.transaction.api.TransactionManager
This will open and run a read-only transaction.
runTaskThrowOnConflict(TransactionTask<T, E>) - Method in interface com.palantir.atlasdb.transaction.api.TransactionManager
runTaskWithConditionReadOnly(C, ConditionAwareTransactionTask<T, C, E>) - Method in interface com.palantir.atlasdb.transaction.api.TransactionManager
This method is basically the same as TransactionManager.runTaskReadOnly(TransactionTask), but it takes a PreCommitCondition and checks it for validity before executing reads.
runTaskWithConditionThrowOnConflict(C, ConditionAwareTransactionTask<T, C, E>) - Method in interface com.palantir.atlasdb.transaction.api.TransactionManager
This method is basically the same as TransactionManager.runTaskThrowOnConflict(TransactionTask), but it takes a PreCommitCondition and checks it immediately before the transaction commits.
runTaskWithConditionWithRetry(Supplier<C>, ConditionAwareTransactionTask<T, C, E>) - Method in interface com.palantir.atlasdb.transaction.api.TransactionManager
runTaskWithConditionWithRetry(Supplier<C>, ConditionAwareTransactionTask<T, C, E>) - Method in interface com.palantir.atlasdb.transaction.api.TransactionManager
This method is basically the same as TransactionManager.runTaskWithRetry(TransactionTask), but it will acquire a PreCommitCondition right before the transaction is created and check it immediately before the transaction commits.
runTaskWithLocksThrowOnConflict(Iterable<HeldLocksToken>, LockAwareTransactionTask<T, E>) - Method in interface com.palantir.atlasdb.transaction.api.TransactionManager
This method is the same as TransactionManager.runTaskThrowOnConflict(TransactionTask) except the created transaction will not commit successfully if these locks are invalid by the time commit is run.
runTaskWithLocksWithRetry(Supplier<LockRequest>, LockAwareTransactionTask<T, E>) - Method in interface com.palantir.atlasdb.transaction.api.TransactionManager
runTaskWithLocksWithRetry(Iterable<HeldLocksToken>, Supplier<LockRequest>, LockAwareTransactionTask<T, E>) - Method in interface com.palantir.atlasdb.transaction.api.TransactionManager
runTaskWithLocksWithRetry(Iterable<HeldLocksToken>, Supplier<LockRequest>, LockAwareTransactionTask<T, E>) - Method in interface com.palantir.atlasdb.transaction.api.TransactionManager
This method is the same as TransactionManager.runTaskWithLocksWithRetry(Supplier, LockAwareTransactionTask) but it will also ensure that the existing lock tokens passed are still valid before committing.
runTaskWithLocksWithRetry(Supplier<LockRequest>, LockAwareTransactionTask<T, E>) - Method in interface com.palantir.atlasdb.transaction.api.TransactionManager
This method is basically the same as TransactionManager.runTaskWithRetry(TransactionTask) but it will acquire locks right before the transaction is created and release them after the task is complete.
runTaskWithRetry(TransactionTask<T, E>) - Method in interface com.palantir.atlasdb.transaction.api.TransactionManager
Runs the given TransactionTask.
RuntimeTransactionTask<T> - Interface in com.palantir.atlasdb.transaction.api
 

S

scrubImmediately(TransactionManager, Multimap<TableReference, Cell>, long, long) - Method in interface com.palantir.atlasdb.cleaner.api.Cleaner
Scrubs cells immediately.
SERIALIZABLE - com.palantir.atlasdb.transaction.api.ConflictHandler
This conflict type does everything that ConflictHandler.RETRY_ON_WRITE_WRITE does but additionally detects and retries on read/write conflict.
SERIALIZABLE_CELL - com.palantir.atlasdb.transaction.api.ConflictHandler
Same as ConflictHandler.SERIALIZABLE, but checks for conflicts by locking cells during commit instead of locking rows.
SERIALIZABLE_INDEX - com.palantir.atlasdb.transaction.api.ConflictHandler
This conflict handler is designed to be used by index tables.
SERIALIZABLE_LOCK_LEVEL_MIGRATION - com.palantir.atlasdb.transaction.api.ConflictHandler
This conflict handler is designed to be used for migrating a table from SERIALIZABLE to SERIALIZABLE_CELL or SERIALIZABLE_INDEX conflict handler, or vice versa without requiring a simultaneous shutdown of all clients.
series() - Method in interface com.palantir.atlasdb.keyvalue.api.TimestampSeries
 
setOnce(TableReference, Map<Cell, byte[]>) - Method in interface com.palantir.atlasdb.keyvalue.api.KeyValueService
Puts a value into the key-value store explicitly overwriting existing entries written by KeyValueService.putUnlessExists(TableReference, Map) and KeyValueService.checkAndSet(CheckAndSetRequest).
setTransactionType(Transaction.TransactionType) - Method in interface com.palantir.atlasdb.transaction.api.Transaction
 
severity() - Method in enum com.palantir.atlasdb.factory.TransactionManagerConsistencyResult.ConsistencyState
 
shard() - Method in class com.palantir.atlasdb.keyvalue.api.TargetedSweepMetadata
 
sharedGetRangesPoolSize() - Method in interface com.palantir.atlasdb.spi.SharedResourcesConfig
 
sharedKvsExecutorSize() - Method in interface com.palantir.atlasdb.spi.SharedResourcesConfig
 
sharedResourcesConfig() - Method in interface com.palantir.atlasdb.spi.KeyValueServiceConfig
 
sharedResourcesConfig() - Method in interface com.palantir.atlasdb.spi.KeyValueServiceConfigHelper
 
SharedResourcesConfig - Interface in com.palantir.atlasdb.spi
 
shouldCheckIfLatestValueIsEmpty() - Method in interface com.palantir.atlasdb.keyvalue.api.CandidateCellForSweepingRequest
In practice, this is true for the THOROUGH sweep strategy and false for CONSERVATIVE.
shouldDeleteGarbageCollectionSentinels() - Method in interface com.palantir.atlasdb.keyvalue.api.CandidateCellForSweepingRequest
Whether GC sentinels (values written at timestamp -1) should be deleted by sweep.
shouldPublish() - Method in interface com.palantir.atlasdb.metrics.MetricPublicationFilter
 
shouldSweep(long) - Method in interface com.palantir.atlasdb.keyvalue.api.CandidateCellForSweepingRequest
 
shouldThrowException() - Method in enum com.palantir.atlasdb.transaction.api.AtlasDbConstraintCheckingMode
 
shouldTriggerCompactions() - Method in interface com.palantir.atlasdb.keyvalue.api.KeyValueService
Whether KeyValueService.compactInternally(TableReference) should be called to free disk space.
singleCell(TableReference, Cell, byte[], byte[]) - Static method in class com.palantir.atlasdb.keyvalue.api.CheckAndSetRequest
 
size() - Method in class com.palantir.atlasdb.keyvalue.api.cache.CacheValue
 
SIZEOF_LONG - Static variable in class com.palantir.atlasdb.encoding.PtBytes
 
SOMEONE_ELSE_IS_THE_LOCK_LEADER - com.palantir.atlasdb.config.LockLeader
 
sortedTimestamps() - Method in interface com.palantir.atlasdb.keyvalue.api.CandidateCellForSweeping
All start timestamps for the cell that are strictly less than CandidateCellForSweepingRequest.maxTimestampExclusive() and are not in CandidateCellForSweepingRequest#timestampsToIgnore(), in ascending order.
sslConfiguration() - Method in class com.palantir.atlasdb.config.LeaderConfig
 
start(TransactionManager) - Method in interface com.palantir.atlasdb.cleaner.api.Cleaner
Starts the background scrubber.
startRowInclusive() - Method in interface com.palantir.atlasdb.keyvalue.api.CandidateCellForSweepingRequest
 
startRowInclusive(byte[]) - Method in class com.palantir.atlasdb.keyvalue.api.RangeRequest.Builder
 
startRowInclusive(Prefix) - Method in class com.palantir.atlasdb.keyvalue.api.RangeRequest.Builder
 
startRowInclusive(Persistable) - Method in class com.palantir.atlasdb.keyvalue.api.RangeRequest.Builder
 
startRowInclusiveOrLargestRow(RangeRequest) - Static method in class com.palantir.atlasdb.keyvalue.api.RangeRequests
This is a replacement for startRow when doing reverse range request.
startsWith(byte[], byte[]) - Static method in class com.palantir.atlasdb.encoding.PtBytes
Return true if the byte array on the right is a prefix of the byte array on the left.
startTransactions(List<? extends PreCommitCondition>) - Method in interface com.palantir.atlasdb.transaction.api.TransactionManager
Deprecated.
Similar functionality will exist, but this method is likely to change in the future
STRICTLY_CHECKED_NAME - Static variable in class com.palantir.atlasdb.keyvalue.api.Namespace
Restrictive name pattern (letters, numbers, and non-initial single underscores).
Supported() - Constructor for class com.palantir.atlasdb.keyvalue.api.CheckAndSetCompatibility.Supported
 
supportedBuilder() - Static method in interface com.palantir.atlasdb.keyvalue.api.CheckAndSetCompatibility
 
supportsCheckAndSet() - Method in interface com.palantir.atlasdb.keyvalue.api.KeyValueService
Check whether CAS is supported.
supportsCheckAndSetOperations() - Method in class com.palantir.atlasdb.keyvalue.api.CheckAndSetCompatibility.Supported
 
supportsCheckAndSetOperations() - Method in interface com.palantir.atlasdb.keyvalue.api.CheckAndSetCompatibility
If false, this KeyValueService does not support check and set operations.
supportsCheckAndSetOperations() - Method in enum com.palantir.atlasdb.keyvalue.api.CheckAndSetCompatibility.Unsupported
 
supportsDetailOnFailure() - Method in interface com.palantir.atlasdb.keyvalue.api.CheckAndSetCompatibility
If false, there are no guarantees that a CheckAndSetException.getActualValues() or KeyAlreadyExistsException.getExistingKeys() from exceptions thrown by the the KeyValueService will actually return any meaningful data (other than the fact that the operation failed).
supportsDetailOnFailure() - Method in enum com.palantir.atlasdb.keyvalue.api.CheckAndSetCompatibility.Unsupported
 
suppressed(Class<E>) - Method in exception com.palantir.atlasdb.keyvalue.api.RetryLimitReachedException
 
SweepResults - Class in com.palantir.atlasdb.keyvalue.api
 
SweepResults() - Constructor for class com.palantir.atlasdb.keyvalue.api.SweepResults
 
SweepResults.Builder - Class in com.palantir.atlasdb.keyvalue.api
 

T

table() - Method in class com.palantir.atlasdb.keyvalue.api.CheckAndSetRequest
 
tableRef() - Method in interface com.palantir.atlasdb.keyvalue.api.AtlasLockDescriptorUtils.TableRefAndRemainder
 
tableRef() - Method in class com.palantir.atlasdb.keyvalue.api.CellReference
 
tableRef() - Method in interface com.palantir.atlasdb.keyvalue.api.MultiCheckAndSetRequest
 
tableRef() - Method in interface com.palantir.atlasdb.transaction.api.GetRangesQuery
 
tableRef() - Method in interface com.palantir.atlasdb.transaction.api.RowReference
 
tableReference() - Method in interface com.palantir.atlasdb.config.DbTimestampCreationSetting
 
TableReference - Class in com.palantir.atlasdb.keyvalue.api
 
tail(byte[], int) - Static method in class com.palantir.atlasdb.encoding.PtBytes
 
TargetedSweepMetadata - Class in com.palantir.atlasdb.keyvalue.api
 
TargetedSweepMetadata() - Constructor for class com.palantir.atlasdb.keyvalue.api.TargetedSweepMetadata
 
TERMINAL - com.palantir.atlasdb.factory.TransactionManagerConsistencyResult.ConsistencyState
Indicates that the transaction manager is in a state that is inconsistent, and automated recovery is generally not possible.
TERMINAL - com.palantir.atlasdb.keyvalue.api.ClusterAvailabilityStatus
 
TERMINAL - com.palantir.atlasdb.transaction.api.KeyValueServiceStatus
 
test(MetricName) - Method in class com.palantir.atlasdb.metrics.MetricPublicationArbiter
 
THROW_EXCEPTION - com.palantir.atlasdb.transaction.api.TransactionReadSentinelBehavior
Throw an exception when a sentinel is read.
throwIfConditionInvalid(long) - Method in interface com.palantir.atlasdb.transaction.api.PreCommitCondition
Checks that the condition is valid at the given timestamp, otherwise throws a TransactionFailedException.
THROWING_FRESH_TIMESTAMP_SOURCE - Static variable in interface com.palantir.atlasdb.spi.AtlasDbFactory
 
TimelockServiceStatus - Enum in com.palantir.atlasdb.transaction.api
 
timestamp() - Method in interface com.palantir.atlasdb.keyvalue.api.TimestampRangeDelete
 
TimestampRangeDelete - Interface in com.palantir.atlasdb.keyvalue.api
 
TimestampRangeDelete.Builder - Class in com.palantir.atlasdb.keyvalue.api
 
timestampSeries() - Method in interface com.palantir.atlasdb.config.DbTimestampCreationSetting
 
TimestampSeries - Interface in com.palantir.atlasdb.keyvalue.api
 
TimestampSeriesProvider - Interface in com.palantir.atlasdb.keyvalue.api
 
toBytes(long) - Static method in class com.palantir.atlasdb.encoding.PtBytes
Convert a long value to a byte array using big-endian.
toBytes(String) - Static method in class com.palantir.atlasdb.encoding.PtBytes
Converts a string to a UTF-8 byte array.
toCachedBytes(String) - Static method in class com.palantir.atlasdb.encoding.PtBytes
Converts a string to a UTF-8 byte array.
toLong(byte[]) - Static method in class com.palantir.atlasdb.encoding.PtBytes
Converts a byte array to a long value.
toLong(byte[], int) - Static method in class com.palantir.atlasdb.encoding.PtBytes
Converts a byte array to a long value.
toString() - Method in class com.palantir.atlasdb.keyvalue.api.BatchColumnRangeSelection
 
toString() - Method in class com.palantir.atlasdb.keyvalue.api.Cell
 
toString() - Method in class com.palantir.atlasdb.keyvalue.api.ColumnRangeSelection
 
toString() - Method in class com.palantir.atlasdb.keyvalue.api.ColumnSelection
 
toString() - Method in class com.palantir.atlasdb.keyvalue.api.Namespace
 
toString() - Method in class com.palantir.atlasdb.keyvalue.api.RangeRequest
 
toString() - Method in class com.palantir.atlasdb.keyvalue.api.RowResult
 
toString() - Method in class com.palantir.atlasdb.keyvalue.api.TableReference
 
toString() - Method in class com.palantir.atlasdb.keyvalue.api.Value
 
toString() - Method in class com.palantir.atlasdb.transaction.api.TransactionConflictException.CellConflict
 
toString(byte[]) - Static method in class com.palantir.atlasdb.encoding.PtBytes
 
toString(byte[], int, int) - Static method in class com.palantir.atlasdb.encoding.PtBytes
 
Transaction - Interface in com.palantir.atlasdb.transaction.api
Provides the methods for a transaction with the key-value store.
Transaction.TransactionType - Enum in com.palantir.atlasdb.transaction.api
 
TransactionCommitFailedException - Exception in com.palantir.atlasdb.transaction.api
This exception type represents a failure during commit where we cannot be sure if the transaction succeeded or not.
TransactionCommitFailedException(String) - Constructor for exception com.palantir.atlasdb.transaction.api.TransactionCommitFailedException
 
TransactionCommitFailedException(String, Throwable) - Constructor for exception com.palantir.atlasdb.transaction.api.TransactionCommitFailedException
 
TransactionConflictException - Exception in com.palantir.atlasdb.transaction.api
Thrown if there is a conflict detected when a transaction is committed.
TransactionConflictException.CellConflict - Class in com.palantir.atlasdb.transaction.api
 
TransactionFailedException - Exception in com.palantir.atlasdb.transaction.api
This is a generic exception for all failures thrown from a Transaction
TransactionFailedNonRetriableException - Exception in com.palantir.atlasdb.transaction.api
 
TransactionFailedNonRetriableException(String) - Constructor for exception com.palantir.atlasdb.transaction.api.TransactionFailedNonRetriableException
 
TransactionFailedNonRetriableException(String, Throwable) - Constructor for exception com.palantir.atlasdb.transaction.api.TransactionFailedNonRetriableException
 
TransactionFailedRetriableException - Exception in com.palantir.atlasdb.transaction.api
This is a generic class of failures that could happen during a transaction where we can retry the transaction.
TransactionFailedRetriableException(String) - Constructor for exception com.palantir.atlasdb.transaction.api.TransactionFailedRetriableException
 
TransactionFailedRetriableException(String, Throwable) - Constructor for exception com.palantir.atlasdb.transaction.api.TransactionFailedRetriableException
 
TransactionLockAcquisitionTimeoutException - Exception in com.palantir.atlasdb.transaction.api
Indicates that we timed out while trying to obtain necessary locks during a transaction.
TransactionLockAcquisitionTimeoutException(String) - Constructor for exception com.palantir.atlasdb.transaction.api.TransactionLockAcquisitionTimeoutException
 
TransactionLockTimeoutException - Exception in com.palantir.atlasdb.transaction.api
The locks to the lock server have timed out.
TransactionLockTimeoutException(String) - Constructor for exception com.palantir.atlasdb.transaction.api.TransactionLockTimeoutException
 
TransactionLockTimeoutException(String, Throwable) - Constructor for exception com.palantir.atlasdb.transaction.api.TransactionLockTimeoutException
 
TransactionLockTimeoutNonRetriableException - Exception in com.palantir.atlasdb.transaction.api
 
TransactionLockTimeoutNonRetriableException(String) - Constructor for exception com.palantir.atlasdb.transaction.api.TransactionLockTimeoutNonRetriableException
 
TransactionLockTimeoutNonRetriableException(String, Throwable) - Constructor for exception com.palantir.atlasdb.transaction.api.TransactionLockTimeoutNonRetriableException
 
TransactionLockWatchFailedException - Exception in com.palantir.atlasdb.transaction.api
 
TransactionLockWatchFailedException(String) - Constructor for exception com.palantir.atlasdb.transaction.api.TransactionLockWatchFailedException
 
TransactionLockWatchFailedException(String, Throwable) - Constructor for exception com.palantir.atlasdb.transaction.api.TransactionLockWatchFailedException
 
TransactionLockWatchingCacheView - Interface in com.palantir.atlasdb.transaction.api
 
TransactionManager - Interface in com.palantir.atlasdb.transaction.api
 
TransactionManagerConsistencyResult - Interface in com.palantir.atlasdb.factory
A TransactionManagerConsistencyResult may be returned from a consistency check, which AtlasDB can execute to determine that it is safe (or, at least, not obviously unsafe) to service requests.
TransactionManagerConsistencyResult.ConsistencyState - Enum in com.palantir.atlasdb.factory
 
TransactionManagerConsistencyResults - Class in com.palantir.atlasdb.factory
 
TransactionReadSentinelBehavior - Enum in com.palantir.atlasdb.transaction.api
This enum handles the different behaviors that can happen as a result of doing reads before the unreadable timestamp.
TransactionScopedCache - Interface in com.palantir.atlasdb.keyvalue.api.cache
The LockWatchValueScopingCache will provide one of these to every (relevant) transaction, and this will contain a view of the cache at the correct point in time, which is determined by the transaction's LockWatchVersion.
TransactionSerializableConflictException - Exception in com.palantir.atlasdb.transaction.api
 
TransactionSerializableConflictException(String, TableReference) - Constructor for exception com.palantir.atlasdb.transaction.api.TransactionSerializableConflictException
 
TransactionService - Interface in com.palantir.atlasdb.transaction.service
Transaction service is used by the atlas protocol to determine is a given transaction has been committed or aborted.
TransactionStatus - Interface in com.palantir.atlasdb.transaction.service
 
TransactionStatus.Cases<R> - Interface in com.palantir.atlasdb.transaction.service
 
TransactionTask<T,​E extends Exception> - Interface in com.palantir.atlasdb.transaction.api
[TO COME: Interface Introduction].
truncateTable(TableReference) - Method in interface com.palantir.atlasdb.keyvalue.api.KeyValueService
Truncate a table in the key-value store.
truncateTables(Set<TableReference>) - Method in interface com.palantir.atlasdb.keyvalue.api.KeyValueService
Truncate tables in the key-value store.
tryCacheNewValuesRead(TableReference, Map<Cell, byte[]>, LockWatchStateUpdate) - Method in class com.palantir.atlasdb.transaction.api.NoOpTransactionLockWatchingCacheView
 
tryCacheNewValuesRead(TableReference, Map<Cell, byte[]>, LockWatchStateUpdate) - Method in interface com.palantir.atlasdb.transaction.api.TransactionLockWatchingCacheView
Try to cache values read from the kvs in this transaction.
tryCacheWrittenValues(TableReference, Map<Cell, byte[]>, long) - Method in class com.palantir.atlasdb.transaction.api.NoOpTransactionLockWatchingCacheView
 
tryCacheWrittenValues(TableReference, Map<Cell, byte[]>, long) - Method in interface com.palantir.atlasdb.transaction.api.TransactionLockWatchingCacheView
Try to cache values written to the kvs in this transaction.
tryParseTableRef(LockDescriptor) - Static method in class com.palantir.atlasdb.keyvalue.api.AtlasLockDescriptorUtils
 
type() - Method in interface com.palantir.atlasdb.spi.KeyValueServiceConfig
 
type() - Method in interface com.palantir.atlasdb.spi.KeyValueServiceConfigHelper
 
type() - Method in interface com.palantir.atlasdb.spi.KeyValueServiceRuntimeConfig
 

U

UNCHECKED_NAME - Static variable in class com.palantir.atlasdb.keyvalue.api.Namespace
Unchecked name pattern (no dots).
UNHEALTHY - com.palantir.atlasdb.transaction.api.KeyValueServiceStatus
 
UNHEALTHY - com.palantir.atlasdb.transaction.api.TimelockServiceStatus
 
unknown() - Method in interface com.palantir.atlasdb.transaction.service.TransactionStatus.Cases
From transaction schema version 4, we have added the ability to truncate the transactions table i.e.
unsupported() - Static method in interface com.palantir.atlasdb.keyvalue.api.CheckAndSetCompatibility
 
updateCacheWithCommitTimestampsInformation(Set<Long>) - Method in interface com.palantir.atlasdb.keyvalue.api.cache.LockWatchValueScopingCache
This does *not* remove state from the cache - LockWatchValueScopingCache.ensureStateRemoved(long) must be called at the end of the transaction to do so, or else there will be a memory leak.
updates() - Method in interface com.palantir.atlasdb.keyvalue.api.MultiCheckAndSetRequest
 
useTable(TableReference, ConstraintCheckable) - Method in interface com.palantir.atlasdb.transaction.api.Transaction
Informs the transaction that a particular table has been written to.

V

value() - Method in class com.palantir.atlasdb.keyvalue.api.cache.CacheValue
 
value() - Method in interface com.palantir.atlasdb.transaction.api.GuardedValue
 
Value - Class in com.palantir.atlasdb.keyvalue.api
Represents a value in the key-value store (including its timestamp).
ValueDigest - Interface in com.palantir.atlasdb.keyvalue.api.cache
 
valueOf(String) - Static method in enum com.palantir.atlasdb.config.LockLeader
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.palantir.atlasdb.factory.TransactionManagerConsistencyResult.ConsistencyState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in class com.palantir.atlasdb.keyvalue.api.BatchColumnRangeSelection
 
valueOf(String) - Static method in enum com.palantir.atlasdb.keyvalue.api.CheckAndSetCompatibility.Unsupported
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.palantir.atlasdb.keyvalue.api.ClusterAvailabilityStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in class com.palantir.atlasdb.keyvalue.api.ColumnRangeSelection
 
valueOf(String) - Static method in class com.palantir.atlasdb.keyvalue.api.ColumnSelection
 
valueOf(String) - Static method in enum com.palantir.atlasdb.transaction.api.AtlasDbConstraintCheckingMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.palantir.atlasdb.transaction.api.ConflictHandler
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.palantir.atlasdb.transaction.api.KeyValueServiceStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.palantir.atlasdb.transaction.api.TimelockServiceStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.palantir.atlasdb.transaction.api.Transaction.TransactionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.palantir.atlasdb.transaction.api.TransactionReadSentinelBehavior
Returns the enum constant of this type with the specified name.
values() - Static method in enum com.palantir.atlasdb.config.LockLeader
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.palantir.atlasdb.factory.TransactionManagerConsistencyResult.ConsistencyState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.palantir.atlasdb.keyvalue.api.CheckAndSetCompatibility.Unsupported
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.palantir.atlasdb.keyvalue.api.ClusterAvailabilityStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.palantir.atlasdb.transaction.api.AtlasDbConstraintCheckingMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.palantir.atlasdb.transaction.api.ConflictHandler
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.palantir.atlasdb.transaction.api.KeyValueServiceStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.palantir.atlasdb.transaction.api.TimelockServiceStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.palantir.atlasdb.transaction.api.Transaction.TransactionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.palantir.atlasdb.transaction.api.TransactionReadSentinelBehavior
Returns an array containing the constants of this enum type, in the order they are declared.
VERSION_UNKNOWN_STRING - Static variable in class com.palantir.atlasdb.versions.AtlasDbVersion
 
visitableProcessor() - Method in interface com.palantir.atlasdb.transaction.api.GetRangesQuery
 

W

withBatchHint(int) - Method in class com.palantir.atlasdb.keyvalue.api.RangeRequest
 
withStartRow(byte[]) - Method in interface com.palantir.atlasdb.keyvalue.api.CandidateCellForSweepingRequest
 
write(TableReference, Map<Cell, byte[]>) - Method in class com.palantir.atlasdb.keyvalue.api.cache.NoOpTransactionScopedCache
 
write(TableReference, Map<Cell, byte[]>) - Method in class com.palantir.atlasdb.keyvalue.api.cache.ReadOnlyTransactionScopedCache
 
write(TableReference, Map<Cell, byte[]>) - Method in interface com.palantir.atlasdb.keyvalue.api.cache.TransactionScopedCache
 
A B C D E F G H I K L M N O P Q R S T U V W 
All Classes All Packages