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

A

abort(Throwable) - Method in class org.apache.tephra.distributed.TransactionService
 
abort(Transaction) - Method in class org.apache.tephra.distributed.TransactionServiceClient
 
abort(Transaction) - Method in class org.apache.tephra.distributed.TransactionServiceThriftClient
 
abort(Transaction) - Method in class org.apache.tephra.inmemory.DetachedTxSystemClient
 
abort(Transaction) - Method in class org.apache.tephra.inmemory.InMemoryTxSystemClient
 
abort(Transaction) - Method in class org.apache.tephra.inmemory.MinimalTxSystemClient
 
abort() - Method in class org.apache.tephra.TransactionContext
Aborts the given transaction, and rolls back all data set changes.
abort(TransactionFailureException) - Method in class org.apache.tephra.TransactionContext
Aborts the given transaction, and rolls back all data set changes.
abort(Transaction) - Method in class org.apache.tephra.TransactionManager
 
abort(Transaction) - Method in interface org.apache.tephra.TransactionSystemClient
Makes transaction visible.
abortTx(TTransaction, AsyncMethodCallback<TTransactionServer.AsyncClient.abortTx_call>) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.AsyncClient
 
abortTx(TTransaction, AsyncMethodCallback<TTransactionServer.AsyncClient.abortTx_call>) - Method in interface org.apache.tephra.distributed.thrift.TTransactionServer.AsyncIface
 
abortTx(TTransaction) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Client
 
abortTx(TTransaction) - Method in interface org.apache.tephra.distributed.thrift.TTransactionServer.Iface
 
abortTx(TTransaction) - Method in class org.apache.tephra.distributed.TransactionServiceThriftHandler
 
AbstractClientProvider - Class in org.apache.tephra.distributed
An abstract tx client provider that implements common functionality.
AbstractClientProvider(Configuration, DiscoveryServiceClient) - Constructor for class org.apache.tephra.distributed.AbstractClientProvider
 
AbstractClientProvider.EndpointStrategy - Interface in org.apache.tephra.distributed
This class helps picking up an endpoint from a list of Discoverable.
AbstractClientProvider.RandomEndpointStrategy - Class in org.apache.tephra.distributed
Randomly picks endpoint from the list of available endpoints.
AbstractClientProvider.RandomEndpointStrategy(Iterable<Discoverable>) - Constructor for class org.apache.tephra.distributed.AbstractClientProvider.RandomEndpointStrategy
Constructs a random endpoint strategy.
AbstractClientProvider.TimeLimitEndpointStrategy - Class in org.apache.tephra.distributed
An AbstractClientProvider.EndpointStrategy that make sure it picks an endpoint within the given timeout limit.
AbstractClientProvider.TimeLimitEndpointStrategy(AbstractClientProvider.EndpointStrategy, long, TimeUnit) - Constructor for class org.apache.tephra.distributed.AbstractClientProvider.TimeLimitEndpointStrategy
 
AbstractTransactionAwareTable - Class in org.apache.tephra
Base class for all the common parts of the HBase version-specific TransactionAwareHTable implementations.
AbstractTransactionAwareTable(TxConstants.ConflictDetection, boolean) - Constructor for class org.apache.tephra.AbstractTransactionAwareTable
 
AbstractTransactionAwareTable.ActionChange - Class in org.apache.tephra
Record of each transaction that causes a change.
AbstractTransactionAwareTable.ActionChange(byte[], byte[]) - Constructor for class org.apache.tephra.AbstractTransactionAwareTable.ActionChange
 
AbstractTransactionAwareTable.ActionChange(byte[], byte[], byte[]) - Constructor for class org.apache.tephra.AbstractTransactionAwareTable.ActionChange
 
AbstractTransactionExecutor - Class in org.apache.tephra
Provides implementation of asynchronous methods of TransactionExecutor by delegating their execution to respective synchronous methods via provided ExecutorService.
AbstractTransactionExecutor(ExecutorService) - Constructor for class org.apache.tephra.AbstractTransactionExecutor
 
AbstractTransactionLog - Class in org.apache.tephra.persist
Common implementation of a transaction log, backed by file reader and writer based storage.
AbstractTransactionLog(long, MetricsCollector) - Constructor for class org.apache.tephra.persist.AbstractTransactionLog
 
AbstractTransactionLog.Entry - Class in org.apache.tephra.persist
Represents an entry in the transaction log.
AbstractTransactionLog.Entry() - Constructor for class org.apache.tephra.persist.AbstractTransactionLog.Entry
 
AbstractTransactionLog.Entry(LongWritable, TransactionEdit) - Constructor for class org.apache.tephra.persist.AbstractTransactionLog.Entry
 
AbstractTransactionStateStorage - Class in org.apache.tephra.persist
Common base class for all transaction storage implementations.
AbstractTransactionStateStorage(SnapshotCodecProvider) - Constructor for class org.apache.tephra.persist.AbstractTransactionStateStorage
 
acceptPolicy(TThreadedSelectorServerWithFix.Args.AcceptPolicy) - Method in class org.apache.thrift.server.TThreadedSelectorServerWithFix.Args
 
acceptQueueSizePerThread(int) - Method in class org.apache.thrift.server.TThreadedSelectorServerWithFix.Args
 
add(long) - Method in class org.apache.tephra.manager.InvalidTxList
 
addAcceptedConnection(TNonblockingTransport) - Method in class org.apache.thrift.server.TThreadedSelectorServerWithFix.SelectorThread
Hands off an accepted connection to be handled by this thread.
addAll(Collection<? extends Long>) - Method in class org.apache.tephra.manager.InvalidTxList
 
addAll(LongList) - Method in class org.apache.tephra.manager.InvalidTxList
 
addCheckpointWritePointer(long) - Method in class org.apache.tephra.TransactionManager.InProgressTx
 
addConnectionWatcher(Watcher) - Method in class org.apache.tephra.zookeeper.TephraZKClientService
 
address - Variable in class org.apache.tephra.inmemory.InMemoryTransactionService
 
addToChanges(ByteBuffer) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_args
 
addToChangeSet(byte[], byte[], byte[]) - Method in class org.apache.tephra.AbstractTransactionAwareTable
 
addToCheckpointWritePointers(long) - Method in class org.apache.tephra.distributed.thrift.TTransaction
 
addToInProgress(long) - Method in class org.apache.tephra.distributed.thrift.TTransaction
 
addToInvalids(long) - Method in class org.apache.tephra.distributed.thrift.TTransaction
 
addToOperation(OperationWithAttributes, Transaction) - Method in class org.apache.tephra.hbase.TransactionAwareHTable
 
addToTxns(long) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTx_args
 
addTransactionAware(TransactionAware) - Method in class org.apache.tephra.TransactionContext
Adds a new transaction-aware to participate in the transaction.
ALL_VISIBLE_LATEST - Static variable in class org.apache.tephra.Transaction
 
ALLOW_EMPTY_VALUES_DEFAULT - Static variable in class org.apache.tephra.TxConstants
 
ALLOW_EMPTY_VALUES_KEY - Static variable in class org.apache.tephra.TxConstants
Since HBase Delete operations cannot be undone at the same timestamp, "deleted" data is instead overwritten with an empty byte[] to flag it as removed.
allowEmptyValues - Variable in class org.apache.tephra.hbase.coprocessor.TransactionProcessor
 
allowNonTransactional - Variable in class org.apache.tephra.AbstractTransactionAwareTable
 
append(Append) - Method in class org.apache.tephra.hbase.TransactionAwareHTable
 
append(TransactionEdit) - Method in class org.apache.tephra.persist.AbstractTransactionLog
 
append(List<TransactionEdit>) - Method in class org.apache.tephra.persist.AbstractTransactionLog
 
append(TransactionEdit) - Method in interface org.apache.tephra.persist.TransactionLog
 
append(List<TransactionEdit>) - Method in interface org.apache.tephra.persist.TransactionLog
 
append(AbstractTransactionLog.Entry) - Method in interface org.apache.tephra.persist.TransactionLogWriter
Adds a new transaction entry to the log.
apply(I) - Method in interface org.apache.tephra.TransactionExecutor.Function
 
apply(I) - Method in interface org.apache.tephra.TransactionExecutor.Procedure
 
apply() - Method in interface org.apache.tephra.TransactionExecutor.Subroutine
 
await(long, TimeUnit) - Method in class org.apache.tephra.visibility.DefaultFenceWait
 
await(long, TimeUnit) - Method in interface org.apache.tephra.visibility.FenceWait
Waits until the fence is complete, or till the timeout specified.

B

BalanceBooks - Class in org.apache.tephra.examples
Simple example application that launches a number of concurrent clients, one per "account".
BalanceBooks(int, int) - Constructor for class org.apache.tephra.examples.BalanceBooks
 
BalanceBooks(int, int, Configuration) - Constructor for class org.apache.tephra.examples.BalanceBooks
 
batch(List<? extends Row>, Object[]) - Method in class org.apache.tephra.hbase.TransactionAwareHTable
 
batch(List<? extends Row>) - Method in class org.apache.tephra.hbase.TransactionAwareHTable
 
batchCallback(List<? extends Row>, Object[], Batch.Callback<R>) - Method in class org.apache.tephra.hbase.TransactionAwareHTable
 
batchCallback(List<? extends Row>, Batch.Callback<R>) - Method in class org.apache.tephra.hbase.TransactionAwareHTable
 
beforeRetry() - Method in class org.apache.tephra.distributed.RetryStrategy
Should be called before re-attempting.
beforeRetry() - Method in class org.apache.tephra.distributed.RetryWithBackoff
 
BinaryDecoder - Class in org.apache.tephra.snapshot
An decoder to help read snapshots in binary format.
BinaryDecoder(InputStream) - Constructor for class org.apache.tephra.snapshot.BinaryDecoder
 
BinaryEncoder - Class in org.apache.tephra.snapshot
An encoder to help encode snapshots in binary format.
BinaryEncoder(OutputStream) - Constructor for class org.apache.tephra.snapshot.BinaryEncoder
 
bufferForSuccess() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.getSnapshot_result
 
build(T) - Method in class org.apache.tephra.rpc.ThriftRPCServer.Builder
 
builder(Class<I>) - Static method in class org.apache.tephra.rpc.ThriftRPCServer
Creates a ThriftRPCServer.Builder for creating instance of ThriftRPCServer.

C

canCommit(Transaction, Collection<byte[]>) - Method in class org.apache.tephra.distributed.TransactionServiceClient
 
canCommit(Transaction, Collection<byte[]>) - Method in class org.apache.tephra.distributed.TransactionServiceThriftClient
 
canCommit(Transaction, Collection<byte[]>) - Method in class org.apache.tephra.inmemory.DetachedTxSystemClient
 
canCommit(Transaction, Collection<byte[]>) - Method in class org.apache.tephra.inmemory.InMemoryTxSystemClient
 
canCommit(Transaction, Collection<byte[]>) - Method in class org.apache.tephra.inmemory.MinimalTxSystemClient
 
canCommit(Transaction, Collection<byte[]>) - Method in class org.apache.tephra.TransactionManager
 
canCommit(Transaction, Collection<byte[]>) - Method in interface org.apache.tephra.TransactionSystemClient
Checks if transaction with the set of changes can be committed.
canCommitTx(TTransaction, Set<ByteBuffer>, AsyncMethodCallback<TTransactionServer.AsyncClient.canCommitTx_call>) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.AsyncClient
 
canCommitTx(TTransaction, Set<ByteBuffer>, AsyncMethodCallback<TTransactionServer.AsyncClient.canCommitTx_call>) - Method in interface org.apache.tephra.distributed.thrift.TTransactionServer.AsyncIface
 
canCommitTx(TTransaction, Set<ByteBuffer>) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Client
 
canCommitTx(TTransaction, Set<ByteBuffer>) - Method in interface org.apache.tephra.distributed.thrift.TTransactionServer.Iface
 
canCommitTx(TTransaction, Set<ByteBuffer>) - Method in class org.apache.tephra.distributed.TransactionServiceThriftHandler
 
CellSkipFilter - Class in org.apache.tephra.hbase.coprocessor
Filter that encapsulates another Filter.
CellSkipFilter(Filter) - Constructor for class org.apache.tephra.hbase.coprocessor.CellSkipFilter
 
CFG_DATA_TX_BIND_ADDRESS - Static variable in class org.apache.tephra.TxConstants.Service
for the address (hostname) of the tx server.
CFG_DATA_TX_BIND_PORT - Static variable in class org.apache.tephra.TxConstants.Service
for the port of the tx server.
CFG_DATA_TX_CLIENT_ATTEMPTS - Static variable in class org.apache.tephra.TxConstants.Service
to specify the number of times to retry a failed thrift call.
CFG_DATA_TX_CLIENT_BACKOFF_FACTOR - Static variable in class org.apache.tephra.TxConstants.Service
to specify the backoff factor for retry strategy backoff.
CFG_DATA_TX_CLIENT_BACKOFF_INITIAL - Static variable in class org.apache.tephra.TxConstants.Service
to specify the initial sleep time for retry strategy backoff.
CFG_DATA_TX_CLIENT_BACKOFF_LIMIT - Static variable in class org.apache.tephra.TxConstants.Service
to specify the sleep time limit for retry strategy backoff.
CFG_DATA_TX_CLIENT_COUNT - Static variable in class org.apache.tephra.TxConstants.Service
to specify the number of threads for client provider "pool".
CFG_DATA_TX_CLIENT_OBTAIN_TIMEOUT_MS - Static variable in class org.apache.tephra.TxConstants.Service
timeout (in milliseconds) for obtaining client from client provider "pool".
CFG_DATA_TX_CLIENT_PROVIDER - Static variable in class org.apache.tephra.TxConstants.Service
to specify the tx client provider strategy.
CFG_DATA_TX_CLIENT_RETRY_STRATEGY - Static variable in class org.apache.tephra.TxConstants.Service
to specify the retry strategy for a failed thrift call.
CFG_DATA_TX_CLIENT_TIMEOUT - Static variable in class org.apache.tephra.TxConstants.Service
to specify the tx client socket timeout in ms.
CFG_DATA_TX_DISCOVERY_SERVICE_NAME - Static variable in class org.apache.tephra.TxConstants.Service
for the name used to announce service availability to discovery service
CFG_DATA_TX_SERVER_IO_THREADS - Static variable in class org.apache.tephra.TxConstants.Service
the number of IO threads in the tx service.
CFG_DATA_TX_SERVER_THREADS - Static variable in class org.apache.tephra.TxConstants.Service
the number of handler threads in the tx service.
CFG_DATA_TX_THRIFT_MAX_READ_BUFFER - Static variable in class org.apache.tephra.TxConstants.Service
 
CFG_DATA_TX_ZOOKEEPER_QUORUM - Static variable in class org.apache.tephra.TxConstants.Service
for the zookeeper quorum string for leader election for tx server.
CFG_DO_PERSIST - Static variable in class org.apache.tephra.TxConstants.Manager
 
CFG_TX_CLEANUP_INTERVAL - Static variable in class org.apache.tephra.TxConstants.Manager
How often to clean up timed out transactions, in seconds, or 0 for no cleanup.
CFG_TX_HDFS_USER - Static variable in class org.apache.tephra.TxConstants.Manager
The user id to access HDFS if not running in secure HDFS.
CFG_TX_LONG_TIMEOUT - Static variable in class org.apache.tephra.TxConstants.Manager
The timeout for a long running transaction, in seconds.
CFG_TX_MAX_LIFETIME - Static variable in class org.apache.tephra.TxConstants.Manager
The maximum time in seconds that a transaction can be used for data writes.
CFG_TX_MAX_TIMEOUT - Static variable in class org.apache.tephra.TxConstants.Manager
The limit for the allowed transaction timeout, in seconds.
CFG_TX_SNAPHOT_CODEC_CLASSES - Static variable in class org.apache.tephra.TxConstants.Persist
The class names of all known transaction snapshot codecs.
CFG_TX_SNAPSHOT_DIR - Static variable in class org.apache.tephra.TxConstants.Manager
Directory in HDFS used for transaction snapshot and log storage.
CFG_TX_SNAPSHOT_INTERVAL - Static variable in class org.apache.tephra.TxConstants.Manager
The frequency (in seconds) to perform periodic snapshots, or 0 for no periodic snapshots.
CFG_TX_SNAPSHOT_LOCAL_DIR - Static variable in class org.apache.tephra.TxConstants.Manager
Directory on the local filesystem used for transaction snapshot and log storage.
CFG_TX_SNAPSHOT_RETAIN - Static variable in class org.apache.tephra.TxConstants.Manager
Number of most recent transaction snapshots to retain.
CFG_TX_TIMEOUT - Static variable in class org.apache.tephra.TxConstants.Manager
The timeout for a transaction, in seconds.
ChangeId - Class in org.apache.tephra
Represents a row key from a data set changed as part of a transaction.
ChangeId(byte[]) - Constructor for class org.apache.tephra.ChangeId
 
changes - Variable in class org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_args
 
changeSets - Variable in class org.apache.tephra.AbstractTransactionAwareTable
 
checkAndDelete(byte[], byte[], byte[], byte[], Delete) - Method in class org.apache.tephra.hbase.TransactionAwareHTable
 
checkAndPut(byte[], byte[], byte[], byte[], Put) - Method in class org.apache.tephra.hbase.TransactionAwareHTable
 
checkpoint(TTransaction, AsyncMethodCallback<TTransactionServer.AsyncClient.checkpoint_call>) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.AsyncClient
 
checkpoint(TTransaction, AsyncMethodCallback<TTransactionServer.AsyncClient.checkpoint_call>) - Method in interface org.apache.tephra.distributed.thrift.TTransactionServer.AsyncIface
 
checkpoint(TTransaction) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Client
 
checkpoint(TTransaction) - Method in interface org.apache.tephra.distributed.thrift.TTransactionServer.Iface
 
checkpoint(Transaction) - Method in class org.apache.tephra.distributed.TransactionServiceClient
 
checkpoint(Transaction) - Method in class org.apache.tephra.distributed.TransactionServiceThriftClient
 
checkpoint(TTransaction) - Method in class org.apache.tephra.distributed.TransactionServiceThriftHandler
 
checkpoint(Transaction) - Method in class org.apache.tephra.inmemory.DetachedTxSystemClient
 
checkpoint(Transaction) - Method in class org.apache.tephra.inmemory.InMemoryTxSystemClient
 
checkpoint(Transaction) - Method in class org.apache.tephra.inmemory.MinimalTxSystemClient
 
checkpoint() - Method in class org.apache.tephra.TransactionContext
Checkpoints the current transaction by flushing any pending writes for the registered TransactionAware instances, and obtaining a new current write pointer for the transaction.
checkpoint(Transaction) - Method in class org.apache.tephra.TransactionManager
 
checkpoint(Transaction) - Method in interface org.apache.tephra.TransactionSystemClient
Performs a checkpoint operation on the current transaction, returning a new Transaction instance with the updated state.
checkpointWritePointers - Variable in class org.apache.tephra.distributed.thrift.TTransaction
 
clear() - Method in class org.apache.tephra.distributed.thrift.TBoolean
 
clear() - Method in exception org.apache.tephra.distributed.thrift.TGenericException
 
clear() - Method in exception org.apache.tephra.distributed.thrift.TInvalidTruncateTimeException
 
clear() - Method in class org.apache.tephra.distributed.thrift.TTransaction
 
clear() - Method in exception org.apache.tephra.distributed.thrift.TTransactionCouldNotTakeSnapshotException
 
clear() - Method in exception org.apache.tephra.distributed.thrift.TTransactionNotInProgressException
 
clear() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.abortTx_args
 
clear() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.abortTx_result
 
clear() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_args
 
clear() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_result
 
clear() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_args
 
clear() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_result
 
clear() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_args
 
clear() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_result
 
clear() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.getSnapshot_args
 
clear() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.getSnapshot_result
 
clear() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidateTx_args
 
clear() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidateTx_result
 
clear() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidTxSize_args
 
clear() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidTxSize_result
 
clear() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.resetState_args
 
clear() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.resetState_result
 
clear() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startLong_args
 
clear() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startLong_result
 
clear() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShort_args
 
clear() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShort_result
 
clear() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortTimeout_args
 
clear() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortTimeout_result
 
clear() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_args
 
clear() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_result
 
clear() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.status_args
 
clear() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.status_result
 
clear() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTx_args
 
clear() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTx_result
 
clear() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_args
 
clear() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_result
 
clear() - Method in class org.apache.tephra.manager.InvalidTxList
 
close() - Method in class org.apache.tephra.distributed.CloseableThriftClient
 
close() - Method in class org.apache.tephra.distributed.TransactionServiceThriftClient
close this client.
close() - Method in class org.apache.tephra.examples.BalanceBooks
Frees up the underlying resources common to all clients.
close() - Method in class org.apache.tephra.hbase.TransactionAwareHTable
 
close() - Method in class org.apache.tephra.persist.AbstractTransactionLog
 
close() - Method in class org.apache.tephra.persist.CommitMarkerCodec
 
close() - Method in class org.apache.tephra.persist.HDFSTransactionLogReaderV1
 
close() - Method in class org.apache.tephra.persist.HDFSTransactionLogReaderV2
 
close() - Method in class org.apache.tephra.persist.HDFSTransactionLogReaderV3
 
close() - Method in interface org.apache.tephra.persist.TransactionLog
 
CloseableThriftClient - Class in org.apache.tephra.distributed
An AutoCloseable to automatically return the thrift client to the ThriftClientProvider.
CloseableThriftClient(ThriftClientProvider, TransactionServiceThriftClient) - Constructor for class org.apache.tephra.distributed.CloseableThriftClient
 
co.cask.tephra.persist - package co.cask.tephra.persist
 
codecProvider - Variable in class org.apache.tephra.persist.AbstractTransactionStateStorage
 
commit(Transaction) - Method in class org.apache.tephra.distributed.TransactionServiceClient
 
commit(Transaction) - Method in class org.apache.tephra.distributed.TransactionServiceThriftClient
 
commit(Transaction) - Method in class org.apache.tephra.inmemory.DetachedTxSystemClient
 
commit(Transaction) - Method in class org.apache.tephra.inmemory.InMemoryTxSystemClient
 
commit(Transaction) - Method in class org.apache.tephra.inmemory.MinimalTxSystemClient
 
commit(Transaction) - Method in class org.apache.tephra.TransactionManager
 
commit(Transaction) - Method in interface org.apache.tephra.TransactionSystemClient
Makes transaction visible.
commitMarker(int) - Method in interface org.apache.tephra.persist.TransactionLogWriter
Makes an entry of number of transaction entries that will follow in that log in a single sync.
CommitMarkerCodec - Class in org.apache.tephra.persist
Class to read and write commit markers used in HDFSTransactionLogReaderV2 and above.
CommitMarkerCodec() - Constructor for class org.apache.tephra.persist.CommitMarkerCodec
 
commitTx() - Method in class org.apache.tephra.AbstractTransactionAwareTable
 
commitTx(TTransaction, AsyncMethodCallback<TTransactionServer.AsyncClient.commitTx_call>) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.AsyncClient
 
commitTx(TTransaction, AsyncMethodCallback<TTransactionServer.AsyncClient.commitTx_call>) - Method in interface org.apache.tephra.distributed.thrift.TTransactionServer.AsyncIface
 
commitTx(TTransaction) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Client
 
commitTx(TTransaction) - Method in interface org.apache.tephra.distributed.thrift.TTransactionServer.Iface
 
commitTx(TTransaction) - Method in class org.apache.tephra.distributed.TransactionServiceThriftHandler
 
commitTx() - Method in interface org.apache.tephra.TransactionAware
Called before transaction has been committed.
CompactionState - Class in org.apache.tephra.hbase.txprune
Record compaction state for invalid list pruning
CompactionState(RegionCoprocessorEnvironment, TableName, long) - Constructor for class org.apache.tephra.hbase.txprune.CompactionState
 
compareTo(TBoolean) - Method in class org.apache.tephra.distributed.thrift.TBoolean
 
compareTo(TGenericException) - Method in exception org.apache.tephra.distributed.thrift.TGenericException
 
compareTo(TInvalidTruncateTimeException) - Method in exception org.apache.tephra.distributed.thrift.TInvalidTruncateTimeException
 
compareTo(TTransaction) - Method in class org.apache.tephra.distributed.thrift.TTransaction
 
compareTo(TTransactionCouldNotTakeSnapshotException) - Method in exception org.apache.tephra.distributed.thrift.TTransactionCouldNotTakeSnapshotException
 
compareTo(TTransactionNotInProgressException) - Method in exception org.apache.tephra.distributed.thrift.TTransactionNotInProgressException
 
compareTo(TTransactionServer.abortTx_args) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.abortTx_args
 
compareTo(TTransactionServer.abortTx_result) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.abortTx_result
 
compareTo(TTransactionServer.canCommitTx_args) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_args
 
compareTo(TTransactionServer.canCommitTx_result) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_result
 
compareTo(TTransactionServer.checkpoint_args) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_args
 
compareTo(TTransactionServer.checkpoint_result) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_result
 
compareTo(TTransactionServer.commitTx_args) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_args
 
compareTo(TTransactionServer.commitTx_result) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_result
 
compareTo(TTransactionServer.getSnapshot_args) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.getSnapshot_args
 
compareTo(TTransactionServer.getSnapshot_result) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.getSnapshot_result
 
compareTo(TTransactionServer.invalidateTx_args) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidateTx_args
 
compareTo(TTransactionServer.invalidateTx_result) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidateTx_result
 
compareTo(TTransactionServer.invalidTxSize_args) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidTxSize_args
 
compareTo(TTransactionServer.invalidTxSize_result) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidTxSize_result
 
compareTo(TTransactionServer.resetState_args) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.resetState_args
 
compareTo(TTransactionServer.resetState_result) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.resetState_result
 
compareTo(TTransactionServer.startLong_args) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startLong_args
 
compareTo(TTransactionServer.startLong_result) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startLong_result
 
compareTo(TTransactionServer.startShort_args) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShort_args
 
compareTo(TTransactionServer.startShort_result) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShort_result
 
compareTo(TTransactionServer.startShortTimeout_args) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortTimeout_args
 
compareTo(TTransactionServer.startShortTimeout_result) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortTimeout_result
 
compareTo(TTransactionServer.startShortWithTimeout_args) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_args
 
compareTo(TTransactionServer.startShortWithTimeout_result) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_result
 
compareTo(TTransactionServer.status_args) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.status_args
 
compareTo(TTransactionServer.status_result) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.status_result
 
compareTo(TTransactionServer.truncateInvalidTx_args) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTx_args
 
compareTo(TTransactionServer.truncateInvalidTx_result) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTx_result
 
compareTo(TTransactionServer.truncateInvalidTxBefore_args) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_args
 
compareTo(TTransactionServer.truncateInvalidTxBefore_result) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_result
 
conf - Variable in class org.apache.tephra.coprocessor.TransactionStateCacheSupplier
 
conf - Variable in class org.apache.tephra.hbase.txprune.HBaseTransactionPruningPlugin
 
ConfigModule - Class in org.apache.tephra.runtime
Provides Guice bindings for Configuration.
ConfigModule(Configuration) - Constructor for class org.apache.tephra.runtime.ConfigModule
 
ConfigurationFactory - Class in org.apache.tephra.util
Provides org.apache.hadoop.conf.Configuration instances, constructed by the correct version used for the runtime.
ConfigurationFactory() - Constructor for class org.apache.tephra.util.ConfigurationFactory
 
ConfigurationProvider - Class in org.apache.tephra.util
Provides Configuration instances, constructed by the HBase version on which we are running.
ConfigurationProvider() - Constructor for class org.apache.tephra.util.ConfigurationProvider
 
configure(Configuration) - Method in class org.apache.tephra.distributed.RetryNTimes.Provider
 
configure(Configuration) - Method in interface org.apache.tephra.distributed.RetryStrategyProvider
Configure the strategy.
configure(Configuration) - Method in class org.apache.tephra.distributed.RetryWithBackoff.Provider
 
configure(Configuration) - Method in class org.apache.tephra.metrics.DefaultMetricsCollector
 
configure(Configuration) - Method in interface org.apache.tephra.metrics.MetricsCollector
Called before the collector service is started, allowing the collector to setup any required configuration.
configure(Configuration) - Method in class org.apache.tephra.metrics.TxMetricsCollector
 
configure() - Method in class org.apache.tephra.runtime.ConfigModule
 
configure() - Method in class org.apache.tephra.runtime.TransactionClientModule
 
configure() - Method in class org.apache.tephra.runtime.TransactionInMemoryModule
 
configure() - Method in class org.apache.tephra.runtime.ZKModule
 
conflictLevel - Variable in class org.apache.tephra.AbstractTransactionAwareTable
 
connection - Variable in class org.apache.tephra.hbase.txprune.HBaseTransactionPruningPlugin
 
contains(long) - Method in class org.apache.tephra.manager.InvalidTxList
 
convertCaskTxEdit(TransactionEdit) - Static method in class org.apache.tephra.persist.TransactionEdit
Deprecated.
coprocessorService(byte[]) - Method in class org.apache.tephra.hbase.TransactionAwareHTable
 
coprocessorService(Class<T>, byte[], byte[], Batch.Call<T, R>) - Method in class org.apache.tephra.hbase.TransactionAwareHTable
 
coprocessorService(Class<T>, byte[], byte[], Batch.Call<T, R>, Batch.Callback<R>) - Method in class org.apache.tephra.hbase.TransactionAwareHTable
 
copyFrom(long, long, long, Collection<Long>, NavigableMap<Long, TransactionManager.InProgressTx>, Map<Long, Set<ChangeId>>, NavigableMap<Long, Set<ChangeId>>) - Static method in class org.apache.tephra.persist.TransactionSnapshot
Creates a new TransactionSnapshot instance with copies of all of the individual collections.
create() - Method in class org.apache.tephra.distributed.ElasticPool
A method to create a new element.
create(String) - Static method in class org.apache.tephra.util.HBaseVersion.VersionNumber
 
create(byte[]) - Static method in class org.apache.tephra.visibility.VisibilityFence
Used by a reader to get a fence that can be added to its transaction context.
create(String, byte[], CreateMode) - Method in class org.apache.tephra.zookeeper.TephraZKClientService
 
create(String, byte[], CreateMode, boolean) - Method in class org.apache.tephra.zookeeper.TephraZKClientService
 
create(String, byte[], CreateMode, Iterable<ACL>) - Method in class org.apache.tephra.zookeeper.TephraZKClientService
 
create(String, byte[], CreateMode, boolean, Iterable<ACL>) - Method in class org.apache.tephra.zookeeper.TephraZKClientService
 
createAborted(long, TransactionType, long[]) - Static method in class co.cask.tephra.persist.TransactionEdit
Deprecated.
Creates a new instance in the TransactionEdit.State.ABORTED state.
createAborted(long, TransactionType, long[]) - Static method in class org.apache.tephra.persist.TransactionEdit
Creates a new instance in the TransactionEdit.State.ABORTED state.
createCheckpoint(long, long) - Static method in class co.cask.tephra.persist.TransactionEdit
Deprecated.
Creates a new instance in the TransactionEdit.State.CHECKPOINT state.
createCheckpoint(long, long) - Static method in class org.apache.tephra.persist.TransactionEdit
Creates a new instance in the TransactionEdit.State.CHECKPOINT state.
createCommitted(long, Set<ChangeId>, long, boolean) - Static method in class co.cask.tephra.persist.TransactionEdit
Deprecated.
Creates a new instance in the TransactionEdit.State.COMMITTED state.
createCommitted(long, Set<ChangeId>, long, boolean) - Static method in class org.apache.tephra.persist.TransactionEdit
Creates a new instance in the TransactionEdit.State.COMMITTED state.
createCommitting(long, Set<ChangeId>) - Static method in class co.cask.tephra.persist.TransactionEdit
Deprecated.
Creates a new instance in the TransactionEdit.State.COMMITTING state.
createCommitting(long, Set<ChangeId>) - Static method in class org.apache.tephra.persist.TransactionEdit
Creates a new instance in the TransactionEdit.State.COMMITTING state.
createDefaultExecutor(TThreadedSelectorServerWithFix.Args) - Static method in class org.apache.thrift.server.TThreadedSelectorServerWithFix
Helper to create the invoker if one is not specified
createDummyTransaction(TransactionVisibilityState) - Static method in class org.apache.tephra.util.TxUtils
Creates a "dummy" transaction based on the given txVisibilityState's state.
createExecutor(Iterable<TransactionAware>) - Method in interface org.apache.tephra.TransactionExecutorFactory
 
createInstance(String) - Method in class org.apache.tephra.util.HBaseVersionSpecificFactory
 
createInvalid(long) - Static method in class co.cask.tephra.persist.TransactionEdit
Deprecated.
Creates a new instance in the TransactionEdit.State.INVALID state.
createInvalid(long) - Static method in class org.apache.tephra.persist.TransactionEdit
Creates a new instance in the TransactionEdit.State.INVALID state.
createLog(long) - Method in class org.apache.tephra.persist.HDFSTransactionStateStorage
 
createLog(long) - Method in class org.apache.tephra.persist.LocalFileTransactionStateStorage
 
createLog(long) - Method in class org.apache.tephra.persist.NoOpTransactionStateStorage
 
createLog(long) - Method in interface org.apache.tephra.persist.TransactionStateStorage
Creates a new TransactionLog.
createMoveWatermark(long) - Static method in class co.cask.tephra.persist.TransactionEdit
Deprecated.
Creates a new instance in the TransactionEdit.State.MOVE_WATERMARK state.
createMoveWatermark(long) - Static method in class org.apache.tephra.persist.TransactionEdit
Creates a new instance in the TransactionEdit.State.MOVE_WATERMARK state.
createPruneTable(TableName) - Method in class org.apache.tephra.hbase.txprune.HBaseTransactionPruningPlugin
Create the prune state table given the TableName if the table doesn't exist already.
createSelectorThreadLoadBalancer(Collection<? extends TThreadedSelectorServerWithFix.SelectorThread>) - Method in class org.apache.thrift.server.TThreadedSelectorServerWithFix
Creates a SelectorThreadLoadBalancer to be used by the accept thread for assigning newly accepted connections across the threads.
createStarted(long, long, long, TransactionType) - Static method in class co.cask.tephra.persist.TransactionEdit
Deprecated.
Creates a new instance in the TransactionEdit.State.INPROGRESS state.
createStarted(long, long, long, TransactionType) - Static method in class org.apache.tephra.persist.TransactionEdit
Creates a new instance in the TransactionEdit.State.INPROGRESS state.
createStoreScanner(RegionCoprocessorEnvironment, String, TransactionVisibilityState, Store, List<? extends KeyValueScanner>, ScanType, long) - Method in class org.apache.tephra.hbase.coprocessor.TransactionProcessor
 
createTableIfNotExists(Configuration, byte[], byte[][]) - Method in class org.apache.tephra.examples.BalanceBooks
 
createTruncateInvalidTx(Set<Long>) - Static method in class co.cask.tephra.persist.TransactionEdit
Deprecated.
Creates a new instance in the TransactionEdit.State.TRUNCATE_INVALID_TX state.
createTruncateInvalidTx(Set<Long>) - Static method in class org.apache.tephra.persist.TransactionEdit
Creates a new instance in the TransactionEdit.State.TRUNCATE_INVALID_TX state.
createTruncateInvalidTxBefore(long) - Static method in class co.cask.tephra.persist.TransactionEdit
Deprecated.
Creates a new instance in the TransactionEdit.State.TRUNCATE_INVALID_TX state.
createTruncateInvalidTxBefore(long) - Static method in class org.apache.tephra.persist.TransactionEdit
Creates a new instance in the TransactionEdit.State.TRUNCATE_INVALID_TX state.
createWriter() - Method in class org.apache.tephra.persist.AbstractTransactionLog
Returns a log writer to be used for appending any new TransactionEdit objects.
createWriter() - Method in class org.apache.tephra.persist.HDFSTransactionLog
 
createWriter() - Method in class org.apache.tephra.persist.LocalFileTransactionLog
 
CURRENT_VERSION - Static variable in class org.apache.tephra.TxConstants.TransactionLog
 

D

DataJanitorState - Class in org.apache.tephra.hbase.txprune
Persist data janitor state into an HBase table.
DataJanitorState(DataJanitorState.TableSupplier) - Constructor for class org.apache.tephra.hbase.txprune.DataJanitorState
 
dataJanitorState - Variable in class org.apache.tephra.hbase.txprune.HBaseTransactionPruningPlugin
 
DataJanitorState.TableSupplier - Interface in org.apache.tephra.hbase.txprune
Supplies table for persisting state
decode(TransactionEdit, DataInput) - Static method in class co.cask.tephra.persist.TransactionEditCodecs
Deprecated.
Deserializes the encoded data from the given input stream, setting the values as fields on the given TransactionEdit instances.
decode(TransactionEdit, DataInput) - Static method in class org.apache.tephra.persist.TransactionEditCodecs
Deserializes the encoded data from the given input stream, setting the values as fields on the given TransactionEdit instances.
decode(InputStream) - Method in class org.apache.tephra.snapshot.DefaultSnapshotCodec
Deprecated.
 
decode(InputStream) - Method in interface org.apache.tephra.snapshot.SnapshotCodec
Decode a transaction snapshot from an input stream.
decode(InputStream) - Method in class org.apache.tephra.snapshot.SnapshotCodecProvider
 
decode(byte[]) - Method in class org.apache.tephra.TransactionCodec
 
decodeInProgress(BinaryDecoder) - Method in class org.apache.tephra.snapshot.DefaultSnapshotCodec
Deprecated.
 
decodeInProgress(BinaryDecoder) - Method in class org.apache.tephra.snapshot.SnapshotCodecV2
 
decodeInProgress(BinaryDecoder) - Method in class org.apache.tephra.snapshot.SnapshotCodecV4
 
decodeTransactionVisibilityState(InputStream) - Method in class org.apache.tephra.snapshot.DefaultSnapshotCodec
Deprecated.
 
decodeTransactionVisibilityState(InputStream) - Method in interface org.apache.tephra.snapshot.SnapshotCodec
Decode transaction visibility state from an input stream.
decodeTransactionVisibilityState(InputStream) - Method in class org.apache.tephra.snapshot.SnapshotCodecProvider
 
deepCopy() - Method in class org.apache.tephra.distributed.thrift.TBoolean
 
deepCopy() - Method in exception org.apache.tephra.distributed.thrift.TGenericException
 
deepCopy() - Method in exception org.apache.tephra.distributed.thrift.TInvalidTruncateTimeException
 
deepCopy() - Method in class org.apache.tephra.distributed.thrift.TTransaction
 
deepCopy() - Method in exception org.apache.tephra.distributed.thrift.TTransactionCouldNotTakeSnapshotException
 
deepCopy() - Method in exception org.apache.tephra.distributed.thrift.TTransactionNotInProgressException
 
deepCopy() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.abortTx_args
 
deepCopy() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.abortTx_result
 
deepCopy() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_args
 
deepCopy() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_result
 
deepCopy() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_args
 
deepCopy() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_result
 
deepCopy() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_args
 
deepCopy() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_result
 
deepCopy() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.getSnapshot_args
 
deepCopy() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.getSnapshot_result
 
deepCopy() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidateTx_args
 
deepCopy() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidateTx_result
 
deepCopy() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidTxSize_args
 
deepCopy() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidTxSize_result
 
deepCopy() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.resetState_args
 
deepCopy() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.resetState_result
 
deepCopy() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startLong_args
 
deepCopy() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startLong_result
 
deepCopy() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShort_args
 
deepCopy() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShort_result
 
deepCopy() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortTimeout_args
 
deepCopy() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortTimeout_result
 
deepCopy() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_args
 
deepCopy() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_result
 
deepCopy() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.status_args
 
deepCopy() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.status_result
 
deepCopy() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTx_args
 
deepCopy() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTx_result
 
deepCopy() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_args
 
deepCopy() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_result
 
DEFAULT_DATA_TX_BIND_ADDRESS - Static variable in class org.apache.tephra.TxConstants.Service
default tx service address.
DEFAULT_DATA_TX_BIND_PORT - Static variable in class org.apache.tephra.TxConstants.Service
default tx service port.
DEFAULT_DATA_TX_CLIENT_ATTEMPTS - Static variable in class org.apache.tephra.TxConstants.Service
default number of attempts for strategy n-times.
DEFAULT_DATA_TX_CLIENT_BACKOFF_FACTOR - Static variable in class org.apache.tephra.TxConstants.Service
default backoff factor is 4.
DEFAULT_DATA_TX_CLIENT_BACKOFF_INITIAL - Static variable in class org.apache.tephra.TxConstants.Service
default initial sleep is 100ms.
DEFAULT_DATA_TX_CLIENT_BACKOFF_LIMIT - Static variable in class org.apache.tephra.TxConstants.Service
default sleep limit is 30 sec.
DEFAULT_DATA_TX_CLIENT_COUNT - Static variable in class org.apache.tephra.TxConstants.Service
default number of tx clients for client provider "pool".
DEFAULT_DATA_TX_CLIENT_OBTAIN_TIMEOUT_MS - Static variable in class org.apache.tephra.TxConstants.Service
default timeout (in milliseconds) for obtaining client from client provider "pool".
DEFAULT_DATA_TX_CLIENT_PROVIDER - Static variable in class org.apache.tephra.TxConstants.Service
default tx client provider strategy.
DEFAULT_DATA_TX_CLIENT_RETRY_STRATEGY - Static variable in class org.apache.tephra.TxConstants.Service
retry strategy for thrift clients, e.g.
DEFAULT_DATA_TX_CLIENT_TIMEOUT_MS - Static variable in class org.apache.tephra.TxConstants.Service
the default tx client socket timeout in milli seconds.
DEFAULT_DATA_TX_DISCOVERY_SERVICE_NAME - Static variable in class org.apache.tephra.TxConstants.Service
 
DEFAULT_DATA_TX_SERVER_IO_THREADS - Static variable in class org.apache.tephra.TxConstants.Service
default number of handler IO threads in tx service.
DEFAULT_DATA_TX_SERVER_THREADS - Static variable in class org.apache.tephra.TxConstants.Service
default number of handler threads in tx service.
DEFAULT_DATA_TX_THRIFT_MAX_READ_BUFFER - Static variable in class org.apache.tephra.TxConstants.Service
default thrift max read buffer size
DEFAULT_PLUGIN - Static variable in class org.apache.tephra.TxConstants.TransactionPruning
 
DEFAULT_PLUGIN_CLASS - Static variable in class org.apache.tephra.TxConstants.TransactionPruning
 
DEFAULT_PRUNE_ENABLE - Static variable in class org.apache.tephra.TxConstants.TransactionPruning
 
DEFAULT_PRUNE_FLUSH_INTERVAL - Static variable in class org.apache.tephra.TxConstants.TransactionPruning
 
DEFAULT_PRUNE_GRACE_PERIOD - Static variable in class org.apache.tephra.TxConstants.TransactionPruning
 
DEFAULT_PRUNE_INTERVAL - Static variable in class org.apache.tephra.TxConstants.TransactionPruning
 
DEFAULT_PRUNE_STATE_TABLE - Static variable in class org.apache.tephra.TxConstants.TransactionPruning
 
DEFAULT_READ_NON_TX_DATA - Static variable in class org.apache.tephra.TxConstants
 
DEFAULT_TX_CLEANUP_INTERVAL - Static variable in class org.apache.tephra.TxConstants.Manager
Default value for how often to check in-progress transactions for expiration, in seconds.
DEFAULT_TX_LONG_TIMEOUT - Static variable in class org.apache.tephra.TxConstants.Manager
Default value for long running transaction timeout, in seconds.
DEFAULT_TX_MAX_LIFETIME - Static variable in class org.apache.tephra.TxConstants.Manager
The default value for the maximum transaction lifetime.
DEFAULT_TX_MAX_TIMEOUT - Static variable in class org.apache.tephra.TxConstants.Manager
The default value for the transaction timeout limit, in seconds: unlimited.
DEFAULT_TX_SNAPHOT_CODEC_CLASSES - Static variable in class org.apache.tephra.TxConstants.Persist
 
DEFAULT_TX_SNAPSHOT_INTERVAL - Static variable in class org.apache.tephra.TxConstants.Manager
Default value for frequency of periodic snapshots of transaction state.
DEFAULT_TX_SNAPSHOT_RETAIN - Static variable in class org.apache.tephra.TxConstants.Manager
Default value for number of most recent snapshots to retain.
DEFAULT_TX_TIMEOUT - Static variable in class org.apache.tephra.TxConstants.Manager
Default value for transaction timeout, in seconds.
DEFAULT_ZK_SESSION_TIMEOUT - Static variable in class org.apache.tephra.TxConstants.HBase
 
DefaultFenceWait - Class in org.apache.tephra.visibility
Default implementation of FenceWait.
DefaultMetricsCollector - Class in org.apache.tephra.metrics
Default metrics collector implementation using Yammer Metrics.
DefaultMetricsCollector() - Constructor for class org.apache.tephra.metrics.DefaultMetricsCollector
 
DefaultSnapshotCodec - Class in org.apache.tephra.snapshot
Deprecated.
This codec is now deprecated and is replaced by SnapshotCodecV2.
DefaultSnapshotCodec() - Constructor for class org.apache.tephra.snapshot.DefaultSnapshotCodec
Deprecated.
 
DefaultTransactionExecutor - Class in org.apache.tephra
Utility class that encapsulates the transaction life cycle over a given set of transaction-aware datasets.
DefaultTransactionExecutor(TransactionSystemClient, TransactionAware...) - Constructor for class org.apache.tephra.DefaultTransactionExecutor
DefaultTransactionExecutor(TransactionSystemClient, Iterable<TransactionAware>, RetryStrategy) - Constructor for class org.apache.tephra.DefaultTransactionExecutor
 
DefaultTransactionExecutor(TransactionSystemClient, Iterable<TransactionAware>) - Constructor for class org.apache.tephra.DefaultTransactionExecutor
Constructor for a transaction executor.
delete(Delete) - Method in class org.apache.tephra.hbase.TransactionAwareHTable
 
delete(List<Delete>) - Method in class org.apache.tephra.hbase.TransactionAwareHTable
 
delete(String) - Method in class org.apache.tephra.zookeeper.TephraZKClientService
 
delete(String, int) - Method in class org.apache.tephra.zookeeper.TephraZKClientService
 
deleteAllRegionsOnOrBeforeTime(long) - Method in class org.apache.tephra.hbase.txprune.DataJanitorState
Delete all the regions that were recorded for all times equal or less than the given time.
deleteEmptyRegionsOnOrBeforeTime(long) - Method in class org.apache.tephra.hbase.txprune.DataJanitorState
Delete empty region records saved on or before the given time.
deleteInactiveTransactionBoundsOnOrBeforeTime(long) - Method in class org.apache.tephra.hbase.txprune.DataJanitorState
Delete all inactive transaction bounds recorded for a time less than the given time
deleteLogsOlderThan(long) - Method in class org.apache.tephra.persist.HDFSTransactionStateStorage
 
deleteLogsOlderThan(long) - Method in class org.apache.tephra.persist.LocalFileTransactionStateStorage
 
deleteLogsOlderThan(long) - Method in class org.apache.tephra.persist.NoOpTransactionStateStorage
 
deleteLogsOlderThan(long) - Method in interface org.apache.tephra.persist.TransactionStateStorage
Removes any transaction logs with a timestamp older than the given value.
deleteOldSnapshots(int) - Method in class org.apache.tephra.persist.HDFSTransactionStateStorage
 
deleteOldSnapshots(int) - Method in class org.apache.tephra.persist.LocalFileTransactionStateStorage
 
deleteOldSnapshots(int) - Method in class org.apache.tephra.persist.NoOpTransactionStateStorage
 
deleteOldSnapshots(int) - Method in interface org.apache.tephra.persist.TransactionStateStorage
Removes any snapshots prior to the numberToKeep most recent.
deletePruneUpperBounds(long, SortedSet<byte[]>) - Method in class org.apache.tephra.hbase.txprune.DataJanitorState
Delete prune upper bounds for the regions that are not in the given exclude set, and the prune upper bound is less than the given value.
destroy() - Method in class org.apache.tephra.distributed.TransactionServiceThriftHandler
 
destroy() - Method in class org.apache.tephra.hbase.txprune.HBaseTransactionPruningPlugin
 
destroy() - Method in class org.apache.tephra.hbase.txprune.InvalidListPruningDebug
 
destroy() - Method in interface org.apache.tephra.rpc.RPCServiceHandler
 
destroy() - Method in class org.apache.tephra.TransactionServiceMain
Invoked by jsvc for resource cleanup.
destroy() - Method in interface org.apache.tephra.txprune.TransactionPruningPlugin
Called once during the shutdown of the Transaction Service.
DetachedTxSystemClient - Class in org.apache.tephra.inmemory
Implementation of the tx system client that doesn't talk to any global service and tries to do its best to meet the tx system requirements/expectations.
DetachedTxSystemClient() - Constructor for class org.apache.tephra.inmemory.DetachedTxSystemClient
 
determineReturnCode(Filter.ReturnCode, Filter.ReturnCode) - Method in class org.apache.tephra.hbase.coprocessor.TransactionVisibilityFilter
Determines the return code of TransactionVisibilityFilter based on sub-filter's return code.
DiscoveryModules - Class in org.apache.tephra.runtime
Provides access to Google Guice modules for in-memory, single-node, and distributed operation for DiscoveryService and DiscoveryServiceClient.
DiscoveryModules() - Constructor for class org.apache.tephra.runtime.DiscoveryModules
 
doCommit() - Method in class org.apache.tephra.AbstractTransactionAwareTable
Commits any pending writes by flushing the wrapped HTable instance.
doCommit() - Method in class org.apache.tephra.hbase.TransactionAwareHTable
 
doMain(boolean, Configuration) - Static method in class org.apache.tephra.distributed.TransactionServiceClient
 
doMain(String[]) - Method in class org.apache.tephra.TransactionServiceMain
The main method.
doRegister() - Method in class org.apache.tephra.inmemory.InMemoryTransactionService
 
doRollback() - Method in class org.apache.tephra.AbstractTransactionAwareTable
Rolls back any persisted changes from the transaction by issuing offsetting deletes to the wrapped HTable instance.
doRollback() - Method in class org.apache.tephra.hbase.TransactionAwareHTable
 
doStart() - Method in class org.apache.tephra.distributed.TransactionService
 
doStart() - Method in class org.apache.tephra.inmemory.InMemoryTransactionService
 
doStart() - Method in class org.apache.tephra.TransactionManager
 
doStart() - Method in class org.apache.tephra.zookeeper.TephraZKClientService
 
doStop() - Method in class org.apache.tephra.distributed.TransactionService
 
doStop() - Method in class org.apache.tephra.inmemory.InMemoryTransactionService
 
doStop() - Method in class org.apache.tephra.TransactionManager
 
doStop() - Method in class org.apache.tephra.zookeeper.TephraZKClientService
 

E

e - Variable in class org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_result
 
e - Variable in class org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_result
 
e - Variable in class org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_result
 
e - Variable in class org.apache.tephra.distributed.thrift.TTransactionServer.getSnapshot_result
 
e - Variable in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_result
 
e - Variable in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_result
 
ElasticPool<T,E extends Exception> - Class in org.apache.tephra.distributed
An Elastic Pool is an object pool that can dynamically grow.
ElasticPool(int) - Constructor for class org.apache.tephra.distributed.ElasticPool
 
encode(TransactionEdit, DataOutput) - Static method in class co.cask.tephra.persist.TransactionEditCodecs
Deprecated.
Serializes the given TransactionEdit instance with the latest available codec.
encode(TransactionEdit, DataOutput) - Static method in class org.apache.tephra.persist.TransactionEditCodecs
Serializes the given TransactionEdit instance with the latest available codec.
encode(OutputStream, TransactionSnapshot) - Method in class org.apache.tephra.snapshot.DefaultSnapshotCodec
Deprecated.
 
encode(OutputStream, TransactionSnapshot) - Method in interface org.apache.tephra.snapshot.SnapshotCodec
Encode a transaction snapshot into an output stream.
encode(OutputStream, TransactionSnapshot) - Method in class org.apache.tephra.snapshot.SnapshotCodecProvider
 
encode(Transaction) - Method in class org.apache.tephra.TransactionCodec
 
encodeInProgress(BinaryEncoder, Map<Long, TransactionManager.InProgressTx>) - Method in class org.apache.tephra.snapshot.DefaultSnapshotCodec
Deprecated.
 
encodeInProgress(BinaryEncoder, Map<Long, TransactionManager.InProgressTx>) - Method in class org.apache.tephra.snapshot.SnapshotCodecV2
 
encodeInProgress(BinaryEncoder, Map<Long, TransactionManager.InProgressTx>) - Method in class org.apache.tephra.snapshot.SnapshotCodecV4
 
ensureValidTxLifetime(RegionCoprocessorEnvironment, OperationWithAttributes, Transaction) - Method in class org.apache.tephra.hbase.coprocessor.TransactionProcessor
Make sure that the transaction is within the max valid transaction lifetime.
equals(Object) - Method in class co.cask.tephra.persist.TransactionEdit
Deprecated.
 
equals(Object) - Method in class org.apache.tephra.AbstractTransactionAwareTable.ActionChange
 
equals(Object) - Method in class org.apache.tephra.ChangeId
 
equals(Object) - Method in class org.apache.tephra.distributed.thrift.TBoolean
 
equals(TBoolean) - Method in class org.apache.tephra.distributed.thrift.TBoolean
 
equals(Object) - Method in exception org.apache.tephra.distributed.thrift.TGenericException
 
equals(TGenericException) - Method in exception org.apache.tephra.distributed.thrift.TGenericException
 
equals(Object) - Method in exception org.apache.tephra.distributed.thrift.TInvalidTruncateTimeException
 
equals(TInvalidTruncateTimeException) - Method in exception org.apache.tephra.distributed.thrift.TInvalidTruncateTimeException
 
equals(Object) - Method in class org.apache.tephra.distributed.thrift.TTransaction
 
equals(TTransaction) - Method in class org.apache.tephra.distributed.thrift.TTransaction
 
equals(Object) - Method in exception org.apache.tephra.distributed.thrift.TTransactionCouldNotTakeSnapshotException
 
equals(TTransactionCouldNotTakeSnapshotException) - Method in exception org.apache.tephra.distributed.thrift.TTransactionCouldNotTakeSnapshotException
 
equals(Object) - Method in exception org.apache.tephra.distributed.thrift.TTransactionNotInProgressException
 
equals(TTransactionNotInProgressException) - Method in exception org.apache.tephra.distributed.thrift.TTransactionNotInProgressException
 
equals(Object) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.abortTx_args
 
equals(TTransactionServer.abortTx_args) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.abortTx_args
 
equals(Object) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.abortTx_result
 
equals(TTransactionServer.abortTx_result) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.abortTx_result
 
equals(Object) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_args
 
equals(TTransactionServer.canCommitTx_args) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_args
 
equals(Object) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_result
 
equals(TTransactionServer.canCommitTx_result) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_result
 
equals(Object) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_args
 
equals(TTransactionServer.checkpoint_args) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_args
 
equals(Object) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_result
 
equals(TTransactionServer.checkpoint_result) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_result
 
equals(Object) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_args
 
equals(TTransactionServer.commitTx_args) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_args
 
equals(Object) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_result
 
equals(TTransactionServer.commitTx_result) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_result
 
equals(Object) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.getSnapshot_args
 
equals(TTransactionServer.getSnapshot_args) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.getSnapshot_args
 
equals(Object) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.getSnapshot_result
 
equals(TTransactionServer.getSnapshot_result) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.getSnapshot_result
 
equals(Object) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidateTx_args
 
equals(TTransactionServer.invalidateTx_args) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidateTx_args
 
equals(Object) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidateTx_result
 
equals(TTransactionServer.invalidateTx_result) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidateTx_result
 
equals(Object) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidTxSize_args
 
equals(TTransactionServer.invalidTxSize_args) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidTxSize_args
 
equals(Object) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidTxSize_result
 
equals(TTransactionServer.invalidTxSize_result) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidTxSize_result
 
equals(Object) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.resetState_args
 
equals(TTransactionServer.resetState_args) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.resetState_args
 
equals(Object) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.resetState_result
 
equals(TTransactionServer.resetState_result) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.resetState_result
 
equals(Object) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startLong_args
 
equals(TTransactionServer.startLong_args) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startLong_args
 
equals(Object) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startLong_result
 
equals(TTransactionServer.startLong_result) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startLong_result
 
equals(Object) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShort_args
 
equals(TTransactionServer.startShort_args) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShort_args
 
equals(Object) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShort_result
 
equals(TTransactionServer.startShort_result) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShort_result
 
equals(Object) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortTimeout_args
 
equals(TTransactionServer.startShortTimeout_args) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortTimeout_args
 
equals(Object) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortTimeout_result
 
equals(TTransactionServer.startShortTimeout_result) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortTimeout_result
 
equals(Object) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_args
 
equals(TTransactionServer.startShortWithTimeout_args) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_args
 
equals(Object) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_result
 
equals(TTransactionServer.startShortWithTimeout_result) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_result
 
equals(Object) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.status_args
 
equals(TTransactionServer.status_args) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.status_args
 
equals(Object) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.status_result
 
equals(TTransactionServer.status_result) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.status_result
 
equals(Object) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTx_args
 
equals(TTransactionServer.truncateInvalidTx_args) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTx_args
 
equals(Object) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTx_result
 
equals(TTransactionServer.truncateInvalidTx_result) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTx_result
 
equals(Object) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_args
 
equals(TTransactionServer.truncateInvalidTxBefore_args) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_args
 
equals(Object) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_result
 
equals(TTransactionServer.truncateInvalidTxBefore_result) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_result
 
equals(Object) - Method in class org.apache.tephra.hbase.txprune.TimeRegions
 
equals(Object) - Method in class org.apache.tephra.persist.TransactionEdit
 
equals(Object) - Method in class org.apache.tephra.persist.TransactionSnapshot
Checks that this instance matches another TransactionSnapshot instance.
equals(Object) - Method in class org.apache.tephra.TransactionManager.InProgressTx
 
equals(Object) - Method in class org.apache.tephra.txprune.RegionPruneInfo
 
excludesSize() - Method in class org.apache.tephra.Transaction
 
execute(TransactionExecutor.Function<I, O>, I) - Method in class org.apache.tephra.DefaultTransactionExecutor
 
execute(TransactionExecutor.Procedure<I>, I) - Method in class org.apache.tephra.DefaultTransactionExecutor
 
execute(Callable<O>) - Method in class org.apache.tephra.DefaultTransactionExecutor
 
execute(TransactionExecutor.Subroutine) - Method in class org.apache.tephra.DefaultTransactionExecutor
 
execute(TransactionExecutor.Function<I, O>, I) - Method in interface org.apache.tephra.TransactionExecutor
Execute a function under transactional semantics.
execute(TransactionExecutor.Procedure<I>, I) - Method in interface org.apache.tephra.TransactionExecutor
Like TransactionExecutor.execute(Function, Object) but without a return value.
execute(Callable<O>) - Method in interface org.apache.tephra.TransactionExecutor
Like TransactionExecutor.execute(Function, Object) but the callable has no argument.
execute(TransactionExecutor.Subroutine) - Method in interface org.apache.tephra.TransactionExecutor
Like TransactionExecutor.execute(Function, Object) but without argument or return value.
executeUnchecked(TransactionExecutor.Function<I, O>, I) - Method in class org.apache.tephra.AbstractTransactionExecutor
 
executeUnchecked(TransactionExecutor.Procedure<I>, I) - Method in class org.apache.tephra.AbstractTransactionExecutor
 
executeUnchecked(Callable<O>) - Method in class org.apache.tephra.AbstractTransactionExecutor
 
executeUnchecked(TransactionExecutor.Subroutine) - Method in class org.apache.tephra.AbstractTransactionExecutor
 
executeUnchecked(TransactionExecutor.Function<I, O>, I) - Method in interface org.apache.tephra.TransactionExecutor
Same as TransactionExecutor.execute(Function, Object) but suppresses exception with Throwables.propagate(Throwable)
executeUnchecked(TransactionExecutor.Procedure<I>, I) - Method in interface org.apache.tephra.TransactionExecutor
Same as TransactionExecutor.execute(Procedure, Object) but suppresses exception with Throwables.propagate(Throwable)
executeUnchecked(Callable<O>) - Method in interface org.apache.tephra.TransactionExecutor
Same as TransactionExecutor.execute(Callable) but suppresses exception with Throwables.propagate(Throwable)
executeUnchecked(TransactionExecutor.Subroutine) - Method in interface org.apache.tephra.TransactionExecutor
Same as TransactionExecutor.execute(Subroutine) but suppresses exception with Throwables.propagate(Throwable)
executorService(ExecutorService) - Method in class org.apache.thrift.server.TThreadedSelectorServerWithFix.Args
 
exists(Get) - Method in class org.apache.tephra.hbase.TransactionAwareHTable
 
exists(List<Get>) - Method in class org.apache.tephra.hbase.TransactionAwareHTable
 
exists(String) - Method in class org.apache.tephra.zookeeper.TephraZKClientService
 
exists(String, Watcher) - Method in class org.apache.tephra.zookeeper.TephraZKClientService
 

F

failOnce() - Method in class org.apache.tephra.distributed.RetryNTimes
 
failOnce() - Method in class org.apache.tephra.distributed.RetryStrategy
Increments the number of failed attempts.
failOnce() - Method in class org.apache.tephra.distributed.RetryWithBackoff
 
FAMILY - Static variable in class org.apache.tephra.hbase.txprune.DataJanitorState
 
FAMILY_DELETE_QUALIFIER - Static variable in class org.apache.tephra.TxConstants
Column qualifier used for a special delete marker tombstone, which identifies an entire column family as deleted.
FenceWait - Interface in org.apache.tephra.visibility
Used by a writer to wait on a fence so that changes are visible to all readers with in-progress transactions.
fetchPruneUpperBound(long, long) - Method in class org.apache.tephra.hbase.txprune.HBaseTransactionPruningPlugin
Determines prune upper bound for the data store as mentioned above.
fetchPruneUpperBound(long, long) - Method in interface org.apache.tephra.txprune.TransactionPruningPlugin
Called periodically to fetch prune upper bound for a data store.
fieldForId(int) - Method in class org.apache.tephra.distributed.thrift.TBoolean
 
fieldForId(int) - Method in exception org.apache.tephra.distributed.thrift.TGenericException
 
fieldForId(int) - Method in exception org.apache.tephra.distributed.thrift.TInvalidTruncateTimeException
 
fieldForId(int) - Method in class org.apache.tephra.distributed.thrift.TTransaction
 
fieldForId(int) - Method in exception org.apache.tephra.distributed.thrift.TTransactionCouldNotTakeSnapshotException
 
fieldForId(int) - Method in exception org.apache.tephra.distributed.thrift.TTransactionNotInProgressException
 
fieldForId(int) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.abortTx_args
 
fieldForId(int) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.abortTx_result
 
fieldForId(int) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_args
 
fieldForId(int) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_result
 
fieldForId(int) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_args
 
fieldForId(int) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_result
 
fieldForId(int) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_args
 
fieldForId(int) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_result
 
fieldForId(int) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.getSnapshot_args
 
fieldForId(int) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.getSnapshot_result
 
fieldForId(int) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidateTx_args
 
fieldForId(int) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidateTx_result
 
fieldForId(int) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidTxSize_args
 
fieldForId(int) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidTxSize_result
 
fieldForId(int) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.resetState_args
 
fieldForId(int) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.resetState_result
 
fieldForId(int) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startLong_args
 
fieldForId(int) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startLong_result
 
fieldForId(int) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShort_args
 
fieldForId(int) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShort_result
 
fieldForId(int) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortTimeout_args
 
fieldForId(int) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortTimeout_result
 
fieldForId(int) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_args
 
fieldForId(int) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_result
 
fieldForId(int) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.status_args
 
fieldForId(int) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.status_result
 
fieldForId(int) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTx_args
 
fieldForId(int) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTx_result
 
fieldForId(int) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_args
 
fieldForId(int) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_result
 
filterAllRemaining() - Method in class org.apache.tephra.hbase.coprocessor.CellSkipFilter
 
filterAllRemaining() - Method in class org.apache.tephra.hbase.coprocessor.TransactionVisibilityFilter
 
filterKeyValue(Cell) - Method in class org.apache.tephra.hbase.coprocessor.CellSkipFilter
 
filterKeyValue(Cell) - Method in class org.apache.tephra.hbase.coprocessor.TransactionVisibilityFilter
 
filterRow() - Method in class org.apache.tephra.hbase.coprocessor.CellSkipFilter
 
filterRow() - Method in class org.apache.tephra.hbase.coprocessor.TransactionVisibilityFilter
 
filterRowCells(List<Cell>) - Method in class org.apache.tephra.hbase.coprocessor.CellSkipFilter
 
filterRowCells(List<Cell>) - Method in class org.apache.tephra.hbase.coprocessor.TransactionVisibilityFilter
 
filterRowKey(byte[], int, int) - Method in class org.apache.tephra.hbase.coprocessor.CellSkipFilter
 
filterRowKey(byte[], int, int) - Method in class org.apache.tephra.hbase.coprocessor.TransactionVisibilityFilter
 
findByName(String) - Static method in enum org.apache.tephra.distributed.thrift.TBoolean._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.tephra.distributed.thrift.TGenericException._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.tephra.distributed.thrift.TInvalidTruncateTimeException._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransaction._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionCouldNotTakeSnapshotException._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionNotInProgressException._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.abortTx_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.abortTx_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.getSnapshot_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.getSnapshot_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.invalidateTx_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.invalidateTx_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.invalidTxSize_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.invalidTxSize_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.resetState_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.resetState_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.startLong_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.startLong_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.startShort_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.startShort_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.startShortTimeout_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.startShortTimeout_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.status_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.status_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTx_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTx_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.tephra.distributed.thrift.TBoolean._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.tephra.distributed.thrift.TGenericException._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.tephra.distributed.thrift.TInvalidTruncateTimeException._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransaction._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionCouldNotTakeSnapshotException._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionNotInProgressException._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.abortTx_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.abortTx_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.getSnapshot_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.getSnapshot_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.invalidateTx_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.invalidateTx_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.invalidTxSize_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.invalidTxSize_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.resetState_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.resetState_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.startLong_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.startLong_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.startShort_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.startShort_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.startShortTimeout_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.startShortTimeout_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.status_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.status_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTx_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTx_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.tephra.distributed.thrift.TBoolean._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.tephra.distributed.thrift.TGenericException._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.tephra.distributed.thrift.TInvalidTruncateTimeException._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransaction._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionCouldNotTakeSnapshotException._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionNotInProgressException._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.abortTx_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.abortTx_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.getSnapshot_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.getSnapshot_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.invalidateTx_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.invalidateTx_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.invalidTxSize_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.invalidTxSize_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.resetState_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.resetState_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.startLong_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.startLong_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.startShort_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.startShort_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.startShortTimeout_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.startShortTimeout_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.status_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.status_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTx_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTx_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByValue(int) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionType
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum org.apache.tephra.distributed.thrift.TVisibilityLevel
Find a the enum type by its integer value, as defined in the Thrift IDL.
finish() - Method in class org.apache.tephra.TransactionContext
Commits the current transaction.
firstShort - Variable in class org.apache.tephra.distributed.thrift.TTransaction
 
flushCommits() - Method in class org.apache.tephra.hbase.TransactionAwareHTable
 

G

gauge(String, int, String...) - Method in class org.apache.tephra.metrics.DefaultMetricsCollector
 
gauge(String, int, String...) - Method in interface org.apache.tephra.metrics.MetricsCollector
Report a metric as an absolute value.
gauge(String, int, String...) - Method in class org.apache.tephra.metrics.TxMetricsCollector
 
get() - Method in class org.apache.tephra.coprocessor.TransactionStateCacheSupplier
Returns a singleton instance of the transaction state cache, performing lazy initialization if necessary.
get() - Method in class org.apache.tephra.hbase.HBase10ConfigurationProvider
 
get(Configuration) - Method in class org.apache.tephra.hbase.HBase10ConfigurationProvider
 
get() - Method in class org.apache.tephra.hbase.HBase11ConfigurationProvider
 
get(Configuration) - Method in class org.apache.tephra.hbase.HBase11ConfigurationProvider
 
get() - Method in class org.apache.tephra.hbase.HBase96ConfigurationProvider
 
get(Configuration) - Method in class org.apache.tephra.hbase.HBase96ConfigurationProvider
 
get() - Method in class org.apache.tephra.hbase.HBase98ConfigurationProvider
 
get(Configuration) - Method in class org.apache.tephra.hbase.HBase98ConfigurationProvider
 
get(Get) - Method in class org.apache.tephra.hbase.SecondaryIndexTable
 
get(List<Get>) - Method in class org.apache.tephra.hbase.SecondaryIndexTable
 
get(Get) - Method in class org.apache.tephra.hbase.TransactionAwareHTable
 
get(List<Get>) - Method in class org.apache.tephra.hbase.TransactionAwareHTable
 
get() - Method in interface org.apache.tephra.hbase.txprune.DataJanitorState.TableSupplier
 
get() - Method in class org.apache.tephra.hbase.txprune.PruneUpperBoundWriterSupplier
 
get() - Method in class org.apache.tephra.persist.HDFSTransactionLogReaderSupplier
 
get() - Method in class org.apache.tephra.runtime.TransactionStateStorageProvider
 
get() - Method in class org.apache.tephra.util.ConfigurationFactory
Returns a new Configuration instance from the HBase version-specific factory.
get(Configuration) - Method in class org.apache.tephra.util.ConfigurationFactory
Returns a new Configuration instance from the HBase version-specific factory.
get() - Method in class org.apache.tephra.util.ConfigurationProvider
 
get(Configuration) - Method in class org.apache.tephra.util.ConfigurationProvider
 
get() - Static method in class org.apache.tephra.util.HBaseVersion
Returns the major version of the currently loaded HBase library.
get() - Method in class org.apache.tephra.util.HBaseVersionSpecificFactory
 
getAcceptPolicy() - Method in class org.apache.thrift.server.TThreadedSelectorServerWithFix.Args
 
getAcceptQueueSizePerThread() - Method in class org.apache.thrift.server.TThreadedSelectorServerWithFix.Args
 
getACL(String) - Method in class org.apache.tephra.zookeeper.TephraZKClientService
 
getAddress() - Method in class org.apache.tephra.distributed.TransactionService
 
getAddress() - Method in class org.apache.tephra.inmemory.InMemoryTransactionService
 
getAllowNonTransactional() - Method in class org.apache.tephra.AbstractTransactionAwareTable
True if the instance allows non-transaction operations.
getAsyncClient(TNonblockingTransport) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.AsyncClient.Factory
 
getBindAddress() - Method in class org.apache.tephra.rpc.ThriftRPCServer
 
getByIndex(byte[]) - Method in class org.apache.tephra.hbase.SecondaryIndexTable
 
getCanCommit() - Method in class co.cask.tephra.persist.TransactionEdit
Deprecated.
Returns whether or not the transaction should be moved to the committed set.
getCanCommit() - Method in class org.apache.tephra.persist.TransactionEdit
Returns whether or not the transaction should be moved to the committed set.
getChangeKey(byte[], byte[], byte[]) - Method in class org.apache.tephra.AbstractTransactionAwareTable
 
getChanges() - Method in class co.cask.tephra.persist.TransactionEdit
Deprecated.
 
getChanges() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_args
 
getChanges() - Method in class org.apache.tephra.persist.TransactionEdit
 
getChangesIterator() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_args
 
getChangesSize() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_args
 
getCheckpointPointers() - Method in class co.cask.tephra.persist.TransactionEdit
Deprecated.
Returns the checkpoint write pointers for the edit.
getCheckpointPointers() - Method in class org.apache.tephra.persist.TransactionEdit
Returns the checkpoint write pointers for the edit.
getCheckpointWritePointers() - Method in class org.apache.tephra.distributed.thrift.TTransaction
 
getCheckpointWritePointers() - Method in class org.apache.tephra.Transaction
Returns any prior write pointers used in the current transaction.
getCheckpointWritePointers() - Method in class org.apache.tephra.TransactionManager.InProgressTx
 
getCheckpointWritePointersIterator() - Method in class org.apache.tephra.distributed.thrift.TTransaction
 
getCheckpointWritePointersSize() - Method in class org.apache.tephra.distributed.thrift.TTransaction
 
getChildren(String) - Method in class org.apache.tephra.zookeeper.TephraZKClientService
 
getChildren(String, Watcher) - Method in class org.apache.tephra.zookeeper.TephraZKClientService
 
getClassifier() - Method in class org.apache.tephra.util.HBaseVersion.VersionNumber
 
getClient(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Client.Factory
 
getClient(TProtocol, TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Client.Factory
 
getCloseableClient() - Method in class org.apache.tephra.distributed.PooledClientProvider
 
getCloseableClient() - Method in class org.apache.tephra.distributed.SingleUseClientProvider
 
getCloseableClient() - Method in class org.apache.tephra.distributed.ThreadLocalClientProvider
 
getCloseableClient() - Method in interface org.apache.tephra.distributed.ThriftClientProvider
Retrieve an AutoCloseable wrapper around tx client for exclusive use by the current thread.
getCommitPointer() - Method in class co.cask.tephra.persist.TransactionEdit
Deprecated.
Returns the write pointer used to commit the row key change set.
getCommitPointer() - Method in class org.apache.tephra.persist.TransactionEdit
Returns the write pointer used to commit the row key change set.
getCommittedChangeSets() - Method in class org.apache.tephra.persist.TransactionSnapshot
Returns a map of transaction write pointer to set of changed row keys for transaction that had successfully called InMemoryTransactionManager.commit(Transaction) at the time of the snapshot.
getCommittingChangeSets() - Method in class org.apache.tephra.persist.TransactionSnapshot
Returns a map of transaction write pointer to sets of changed row keys for transactions that had called InMemoryTransactionManager.canCommit(Transaction, Collection) but not yet called InMemoryTransactionManager.commit(Transaction) at the time of the snapshot.
getConf() - Method in class org.apache.tephra.coprocessor.TransactionStateCache
 
getConfiguration(CoprocessorEnvironment) - Method in class org.apache.tephra.hbase.coprocessor.TransactionProcessor
Fetch the Configuration that contains the properties required by the coprocessor.
getConfiguration() - Method in class org.apache.tephra.hbase.TransactionAwareHTable
 
getConnectString() - Method in class org.apache.tephra.zookeeper.TephraZKClientService
 
getCurrentState() - Method in class org.apache.tephra.TransactionManager
 
getCurrentTransaction() - Method in class org.apache.tephra.TransactionContext
Returns the current transaction or null if no transaction is currently in progress.
getData(String) - Method in class org.apache.tephra.zookeeper.TephraZKClientService
 
getData(String, Watcher) - Method in class org.apache.tephra.zookeeper.TephraZKClientService
 
getDistributedModules() - Method in class org.apache.tephra.runtime.DiscoveryModules
 
getDistributedModules() - Method in class org.apache.tephra.runtime.TransactionModules
 
getE() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_result
 
getE() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_result
 
getE() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_result
 
getE() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.getSnapshot_result
 
getE() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_result
 
getE() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_result
 
getEdit() - Method in class org.apache.tephra.persist.AbstractTransactionLog.Entry
 
getEmptyArgsInstance() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Processor.abortTx
 
getEmptyArgsInstance() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Processor.canCommitTx
 
getEmptyArgsInstance() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Processor.checkpoint
 
getEmptyArgsInstance() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Processor.commitTx
 
getEmptyArgsInstance() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Processor.getSnapshot
 
getEmptyArgsInstance() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Processor.invalidateTx
 
getEmptyArgsInstance() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Processor.invalidTxSize
 
getEmptyArgsInstance() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Processor.resetState
 
getEmptyArgsInstance() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Processor.startLong
 
getEmptyArgsInstance() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Processor.startShort
 
getEmptyArgsInstance() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Processor.startShortTimeout
 
getEmptyArgsInstance() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Processor.startShortWithTimeout
 
getEmptyArgsInstance() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Processor.status
 
getEmptyArgsInstance() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Processor.truncateInvalidTx
 
getEmptyArgsInstance() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Processor.truncateInvalidTxBefore
 
getEmptyRegionsAfterTime(long, SortedSet<byte[]>) - Method in class org.apache.tephra.hbase.txprune.DataJanitorState
Return regions that were recorded as empty after the given time.
getExcludedListSize() - Method in class org.apache.tephra.TransactionManager
 
getExecutorService() - Method in class org.apache.thrift.server.TThreadedSelectorServerWithFix.Args
 
getExpiration() - Method in class co.cask.tephra.persist.TransactionEdit
Deprecated.
Returns any expiration timestamp (in milliseconds) associated with the state change.
getExpiration() - Method in class org.apache.tephra.persist.TransactionEdit
Returns any expiration timestamp (in milliseconds) associated with the state change.
getExpiration() - Method in class org.apache.tephra.TransactionManager.InProgressTx
 
getFamily() - Method in class org.apache.tephra.AbstractTransactionAwareTable.ActionChange
 
getFieldName() - Method in enum org.apache.tephra.distributed.thrift.TBoolean._Fields
 
getFieldName() - Method in enum org.apache.tephra.distributed.thrift.TGenericException._Fields
 
getFieldName() - Method in enum org.apache.tephra.distributed.thrift.TInvalidTruncateTimeException._Fields
 
getFieldName() - Method in enum org.apache.tephra.distributed.thrift.TTransaction._Fields
 
getFieldName() - Method in enum org.apache.tephra.distributed.thrift.TTransactionCouldNotTakeSnapshotException._Fields
 
getFieldName() - Method in enum org.apache.tephra.distributed.thrift.TTransactionNotInProgressException._Fields
 
getFieldName() - Method in enum org.apache.tephra.distributed.thrift.TTransactionServer.abortTx_args._Fields
 
getFieldName() - Method in enum org.apache.tephra.distributed.thrift.TTransactionServer.abortTx_result._Fields
 
getFieldName() - Method in enum org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_args._Fields
 
getFieldName() - Method in enum org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_result._Fields
 
getFieldName() - Method in enum org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_args._Fields
 
getFieldName() - Method in enum org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_result._Fields
 
getFieldName() - Method in enum org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_args._Fields
 
getFieldName() - Method in enum org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_result._Fields
 
getFieldName() - Method in enum org.apache.tephra.distributed.thrift.TTransactionServer.getSnapshot_args._Fields
 
getFieldName() - Method in enum org.apache.tephra.distributed.thrift.TTransactionServer.getSnapshot_result._Fields
 
getFieldName() - Method in enum org.apache.tephra.distributed.thrift.TTransactionServer.invalidateTx_args._Fields
 
getFieldName() - Method in enum org.apache.tephra.distributed.thrift.TTransactionServer.invalidateTx_result._Fields
 
getFieldName() - Method in enum org.apache.tephra.distributed.thrift.TTransactionServer.invalidTxSize_args._Fields
 
getFieldName() - Method in enum org.apache.tephra.distributed.thrift.TTransactionServer.invalidTxSize_result._Fields
 
getFieldName() - Method in enum org.apache.tephra.distributed.thrift.TTransactionServer.resetState_args._Fields
 
getFieldName() - Method in enum org.apache.tephra.distributed.thrift.TTransactionServer.resetState_result._Fields
 
getFieldName() - Method in enum org.apache.tephra.distributed.thrift.TTransactionServer.startLong_args._Fields
 
getFieldName() - Method in enum org.apache.tephra.distributed.thrift.TTransactionServer.startLong_result._Fields
 
getFieldName() - Method in enum org.apache.tephra.distributed.thrift.TTransactionServer.startShort_args._Fields
 
getFieldName() - Method in enum org.apache.tephra.distributed.thrift.TTransactionServer.startShort_result._Fields
 
getFieldName() - Method in enum org.apache.tephra.distributed.thrift.TTransactionServer.startShortTimeout_args._Fields
 
getFieldName() - Method in enum org.apache.tephra.distributed.thrift.TTransactionServer.startShortTimeout_result._Fields
 
getFieldName() - Method in enum org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_args._Fields
 
getFieldName() - Method in enum org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_result._Fields
 
getFieldName() - Method in enum org.apache.tephra.distributed.thrift.TTransactionServer.status_args._Fields
 
getFieldName() - Method in enum org.apache.tephra.distributed.thrift.TTransactionServer.status_result._Fields
 
getFieldName() - Method in enum org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTx_args._Fields
 
getFieldName() - Method in enum org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTx_result._Fields
 
getFieldName() - Method in enum org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_args._Fields
 
getFieldName() - Method in enum org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_result._Fields
 
getFieldValue(TBoolean._Fields) - Method in class org.apache.tephra.distributed.thrift.TBoolean
 
getFieldValue(TGenericException._Fields) - Method in exception org.apache.tephra.distributed.thrift.TGenericException
 
getFieldValue(TInvalidTruncateTimeException._Fields) - Method in exception org.apache.tephra.distributed.thrift.TInvalidTruncateTimeException
 
getFieldValue(TTransaction._Fields) - Method in class org.apache.tephra.distributed.thrift.TTransaction
 
getFieldValue(TTransactionCouldNotTakeSnapshotException._Fields) - Method in exception org.apache.tephra.distributed.thrift.TTransactionCouldNotTakeSnapshotException
 
getFieldValue(TTransactionNotInProgressException._Fields) - Method in exception org.apache.tephra.distributed.thrift.TTransactionNotInProgressException
 
getFieldValue(TTransactionServer.abortTx_args._Fields) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.abortTx_args
 
getFieldValue(TTransactionServer.abortTx_result._Fields) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.abortTx_result
 
getFieldValue(TTransactionServer.canCommitTx_args._Fields) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_args
 
getFieldValue(TTransactionServer.canCommitTx_result._Fields) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_result
 
getFieldValue(TTransactionServer.checkpoint_args._Fields) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_args
 
getFieldValue(TTransactionServer.checkpoint_result._Fields) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_result
 
getFieldValue(TTransactionServer.commitTx_args._Fields) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_args
 
getFieldValue(TTransactionServer.commitTx_result._Fields) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_result
 
getFieldValue(TTransactionServer.getSnapshot_args._Fields) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.getSnapshot_args
 
getFieldValue(TTransactionServer.getSnapshot_result._Fields) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.getSnapshot_result
 
getFieldValue(TTransactionServer.invalidateTx_args._Fields) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidateTx_args
 
getFieldValue(TTransactionServer.invalidateTx_result._Fields) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidateTx_result
 
getFieldValue(TTransactionServer.invalidTxSize_args._Fields) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidTxSize_args
 
getFieldValue(TTransactionServer.invalidTxSize_result._Fields) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidTxSize_result
 
getFieldValue(TTransactionServer.resetState_args._Fields) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.resetState_args
 
getFieldValue(TTransactionServer.resetState_result._Fields) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.resetState_result
 
getFieldValue(TTransactionServer.startLong_args._Fields) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startLong_args
 
getFieldValue(TTransactionServer.startLong_result._Fields) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startLong_result
 
getFieldValue(TTransactionServer.startShort_args._Fields) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShort_args
 
getFieldValue(TTransactionServer.startShort_result._Fields) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShort_result
 
getFieldValue(TTransactionServer.startShortTimeout_args._Fields) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortTimeout_args
 
getFieldValue(TTransactionServer.startShortTimeout_result._Fields) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortTimeout_result
 
getFieldValue(TTransactionServer.startShortWithTimeout_args._Fields) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_args
 
getFieldValue(TTransactionServer.startShortWithTimeout_result._Fields) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_result
 
getFieldValue(TTransactionServer.status_args._Fields) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.status_args
 
getFieldValue(TTransactionServer.status_result._Fields) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.status_result
 
getFieldValue(TTransactionServer.truncateInvalidTx_args._Fields) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTx_args
 
getFieldValue(TTransactionServer.truncateInvalidTx_result._Fields) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTx_result
 
getFieldValue(TTransactionServer.truncateInvalidTxBefore_args._Fields) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_args
 
getFieldValue(TTransactionServer.truncateInvalidTxBefore_result._Fields) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_result
 
getFirstInProgress() - Method in class org.apache.tephra.Transaction
 
getFirstShort() - Method in class org.apache.tephra.distributed.thrift.TTransaction
 
getFirstShortInProgress() - Method in class org.apache.tephra.Transaction
 
getFirstShortInProgress(Map<Long, TransactionManager.InProgressTx>) - Static method in class org.apache.tephra.util.TxUtils
Returns the write pointer for the first "short" transaction that in the in-progress set, or Transaction.NO_TX_IN_PROGRESS if none.
getHBase10CDHClassname() - Method in class org.apache.tephra.util.HBaseVersionSpecificFactory
 
getHBase10Classname() - Method in class org.apache.tephra.util.HBaseVersionSpecificFactory
 
getHBase11Classname() - Method in class org.apache.tephra.util.HBaseVersionSpecificFactory
 
getHBase96Classname() - Method in class org.apache.tephra.util.HBaseVersionSpecificFactory
 
getHBase98Classname() - Method in class org.apache.tephra.util.HBaseVersionSpecificFactory
 
getIdleRegions(Integer) - Method in class org.apache.tephra.hbase.txprune.InvalidListPruningDebug
Return a list of RegionPruneInfo.
getInactiveTransactionBoundForTime(long) - Method in class org.apache.tephra.hbase.txprune.DataJanitorState
Return inactive transaction bound for the given time.
getInactiveTxBound(long, long) - Static method in class org.apache.tephra.util.TxUtils
Returns the greatest transaction that has passed the maximum duration a transaction can be used for data writes.
getInMemoryModules() - Method in class org.apache.tephra.runtime.DiscoveryModules
 
getInMemoryModules() - Method in class org.apache.tephra.runtime.TransactionModules
 
getInProgress() - Method in class org.apache.tephra.distributed.thrift.TTransaction
 
getInProgress() - Method in class org.apache.tephra.persist.TransactionSnapshot
 
getInProgress() - Method in interface org.apache.tephra.persist.TransactionVisibilityState
Returns the map of write pointers to in-progress transactions at the time of the snapshot.
getInProgress() - Method in class org.apache.tephra.Transaction
 
getInProgressIterator() - Method in class org.apache.tephra.distributed.thrift.TTransaction
 
getInProgressSize() - Method in class org.apache.tephra.distributed.thrift.TTransaction
 
getInvalid() - Method in class org.apache.tephra.persist.TransactionSnapshot
 
getInvalid() - Method in interface org.apache.tephra.persist.TransactionVisibilityState
Returns the list of invalid write pointers at the time of the snapshot.
getInvalids() - Method in class org.apache.tephra.distributed.thrift.TTransaction
 
getInvalids() - Method in class org.apache.tephra.Transaction
 
getInvalidsIterator() - Method in class org.apache.tephra.distributed.thrift.TTransaction
 
getInvalidSize() - Method in class org.apache.tephra.distributed.TransactionServiceClient
 
getInvalidSize() - Method in class org.apache.tephra.distributed.TransactionServiceThriftClient
 
getInvalidSize() - Method in class org.apache.tephra.inmemory.DetachedTxSystemClient
 
getInvalidSize() - Method in class org.apache.tephra.inmemory.InMemoryTxSystemClient
 
getInvalidSize() - Method in class org.apache.tephra.inmemory.MinimalTxSystemClient
 
getInvalidSize() - Method in class org.apache.tephra.TransactionManager
 
getInvalidSize() - Method in interface org.apache.tephra.TransactionSystemClient
 
getInvalidsSize() - Method in class org.apache.tephra.distributed.thrift.TTransaction
 
getKey() - Method in class org.apache.tephra.ChangeId
 
getKey() - Method in class org.apache.tephra.persist.AbstractTransactionLog.Entry
 
getLast() - Method in class org.apache.tephra.util.HBaseVersion.VersionNumber
 
getLatestSnapshot() - Method in class org.apache.tephra.persist.HDFSTransactionStateStorage
 
getLatestSnapshot() - Method in class org.apache.tephra.persist.LocalFileTransactionStateStorage
 
getLatestSnapshot() - Method in class org.apache.tephra.persist.NoOpTransactionStateStorage
 
getLatestSnapshot() - Method in interface org.apache.tephra.persist.TransactionStateStorage
Returns the most recent snapshot that has been successfully written.
getLatestState() - Method in class org.apache.tephra.coprocessor.TransactionStateCache
 
getLatestTransactionVisibilityState() - Method in class org.apache.tephra.persist.HDFSTransactionStateStorage
 
getLatestTransactionVisibilityState() - Method in class org.apache.tephra.persist.LocalFileTransactionStateStorage
 
getLatestTransactionVisibilityState() - Method in class org.apache.tephra.persist.NoOpTransactionStateStorage
 
getLatestTransactionVisibilityState() - Method in interface org.apache.tephra.persist.TransactionStateStorage
Returns the most recent transaction visibility state that has been successfully written.
getLocation() - Method in class org.apache.tephra.persist.HDFSTransactionStateStorage
 
getLocation() - Method in class org.apache.tephra.persist.LocalFileTransactionStateStorage
 
getLocation() - Method in class org.apache.tephra.persist.NoOpTransactionStateStorage
 
getLocation() - Method in interface org.apache.tephra.persist.TransactionStateStorage
Returns a string representation of the location used for persistence.
getLogsSince(long) - Method in class org.apache.tephra.persist.HDFSTransactionStateStorage
 
getLogsSince(long) - Method in class org.apache.tephra.persist.LocalFileTransactionStateStorage
 
getLogsSince(long) - Method in class org.apache.tephra.persist.NoOpTransactionStateStorage
 
getLogsSince(long) - Method in interface org.apache.tephra.persist.TransactionStateStorage
Returns all TransactionLogs with a timestamp greater than or equal to the given timestamp.
getMajor() - Method in class org.apache.tephra.util.HBaseVersion.VersionNumber
 
getMajorVersion() - Method in enum org.apache.tephra.util.HBaseVersion.Version
 
getMaxVisibleTimestamp(Transaction) - Static method in class org.apache.tephra.util.TxUtils
Returns the maximum timestamp to use for time-range operations, based on the given transaction.
getMessage() - Method in exception org.apache.tephra.distributed.thrift.TGenericException
 
getMessage() - Method in exception org.apache.tephra.distributed.thrift.TInvalidTruncateTimeException
 
getMessage() - Method in exception org.apache.tephra.distributed.thrift.TTransactionCouldNotTakeSnapshotException
 
getMessage() - Method in exception org.apache.tephra.distributed.thrift.TTransactionNotInProgressException
 
getMinor() - Method in class org.apache.tephra.util.HBaseVersion.VersionNumber
 
getName() - Method in class org.apache.tephra.hbase.TransactionAwareHTable
 
getName() - Method in class org.apache.tephra.persist.AbstractTransactionLog
 
getName() - Method in class org.apache.tephra.persist.HDFSTransactionLog
 
getName() - Method in class org.apache.tephra.persist.LocalFileTransactionLog
 
getName() - Method in interface org.apache.tephra.persist.TransactionLog
 
getNextCellHint(Cell) - Method in class org.apache.tephra.hbase.coprocessor.CellSkipFilter
 
getNextCellHint(Cell) - Method in class org.apache.tephra.hbase.coprocessor.TransactionVisibilityFilter
 
getNextKeyHint(KeyValue) - Method in class org.apache.tephra.hbase.coprocessor.CellSkipFilter
 
getNextKeyHint(KeyValue) - Method in class org.apache.tephra.hbase.coprocessor.TransactionVisibilityFilter
 
getOldestVisibleTimestamp(Map<byte[], Long>, Transaction) - Static method in class org.apache.tephra.util.TxUtils
Returns the oldest visible timestamp for the given transaction, based on the TTLs configured for each column family.
getOldestVisibleTimestamp(Map<byte[], Long>, Transaction, boolean) - Static method in class org.apache.tephra.util.TxUtils
Returns the oldest visible timestamp for the given transaction, based on the TTLs configured for each column family.
getOriginalExceptionClass() - Method in exception org.apache.tephra.distributed.thrift.TGenericException
 
getParentWritePointer() - Method in class co.cask.tephra.persist.TransactionEdit
Deprecated.
Returns the parent write pointer for a checkpoint operation.
getParentWritePointer() - Method in class org.apache.tephra.persist.TransactionEdit
Returns the parent write pointer for a checkpoint operation.
getPatch() - Method in class org.apache.tephra.util.HBaseVersion.VersionNumber
 
getPruneInfoForRegion(byte[]) - Method in class org.apache.tephra.hbase.txprune.DataJanitorState
Get the latest RegionPruneInfo for a given region.
getPruneInfoForRegions(SortedSet<byte[]>) - Method in class org.apache.tephra.hbase.txprune.DataJanitorState
Gets a list of RegionPruneInfo for given regions.
getPruneRecordTime() - Method in class org.apache.tephra.txprune.RegionPruneInfo
 
getPruneUpperBound() - Method in class org.apache.tephra.txprune.RegionPruneInfo
 
getPruneUpperBound(Transaction) - Static method in class org.apache.tephra.util.TxUtils
Returns the maximum transaction that can be removed from the invalid list for the state represented by the given transaction.
getPruneUpperBoundForRegion(byte[]) - Method in class org.apache.tephra.hbase.txprune.DataJanitorState
Get latest prune upper bound for a given region.
getPruneUpperBoundForRegions(SortedSet<byte[]>) - Method in class org.apache.tephra.hbase.txprune.DataJanitorState
Get latest prune upper bounds for given regions.
getQualifier() - Method in class org.apache.tephra.AbstractTransactionAwareTable.ActionChange
 
getReader() - Method in class org.apache.tephra.persist.AbstractTransactionLog
 
getReader() - Method in class org.apache.tephra.persist.HDFSTransactionLog
 
getReader() - Method in class org.apache.tephra.persist.LocalFileTransactionLog
 
getReader() - Method in interface org.apache.tephra.persist.TransactionLog
 
getReadPointer() - Method in class org.apache.tephra.distributed.thrift.TTransaction
 
getReadPointer() - Method in class org.apache.tephra.persist.TransactionSnapshot
 
getReadPointer() - Method in interface org.apache.tephra.persist.TransactionVisibilityState
Returns the read pointer at the time of the snapshot.
getReadPointer() - Method in class org.apache.tephra.Transaction
 
getRegionName() - Method in class org.apache.tephra.txprune.RegionPruneInfo
 
getRegionNameAsString() - Method in class org.apache.tephra.txprune.RegionPruneInfo
 
getRegionPruneInfo(String) - Method in class org.apache.tephra.hbase.txprune.InvalidListPruningDebug
Return the prune upper bound value of a given region.
getRegions() - Method in class org.apache.tephra.hbase.txprune.TimeRegions
 
getRegionsOnOrBeforeTime(long) - Method in class org.apache.tephra.hbase.txprune.DataJanitorState
Return the set of regions saved for the time at or before the given time.
getRegionsOnOrBeforeTime(Long) - Method in class org.apache.tephra.hbase.txprune.InvalidListPruningDebug
 
getRegionsToBeCompacted(Integer) - Method in class org.apache.tephra.hbase.txprune.InvalidListPruningDebug
Returns a set of regions that are live but are not empty nor have a prune upper bound recorded.
getResult() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.AsyncClient.abortTx_call
 
getResult() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.AsyncClient.canCommitTx_call
 
getResult() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.AsyncClient.checkpoint_call
 
getResult() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.AsyncClient.commitTx_call
 
getResult() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.AsyncClient.getSnapshot_call
 
getResult() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.AsyncClient.invalidateTx_call
 
getResult() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.AsyncClient.invalidTxSize_call
 
getResult() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.AsyncClient.resetState_call
 
getResult() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.AsyncClient.startLong_call
 
getResult() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.AsyncClient.startShort_call
 
getResult() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.AsyncClient.startShortTimeout_call
 
getResult() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.AsyncClient.startShortWithTimeout_call
 
getResult() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.AsyncClient.status_call
 
getResult() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.AsyncClient.truncateInvalidTx_call
 
getResult() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.AsyncClient.truncateInvalidTxBefore_call
 
getResult(I, TTransactionServer.abortTx_args) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Processor.abortTx
 
getResult(I, TTransactionServer.canCommitTx_args) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Processor.canCommitTx
 
getResult(I, TTransactionServer.checkpoint_args) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Processor.checkpoint
 
getResult(I, TTransactionServer.commitTx_args) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Processor.commitTx
 
getResult(I, TTransactionServer.getSnapshot_args) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Processor.getSnapshot
 
getResult(I, TTransactionServer.invalidateTx_args) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Processor.invalidateTx
 
getResult(I, TTransactionServer.invalidTxSize_args) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Processor.invalidTxSize
 
getResult(I, TTransactionServer.resetState_args) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Processor.resetState
 
getResult(I, TTransactionServer.startLong_args) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Processor.startLong
 
getResult(I, TTransactionServer.startShort_args) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Processor.startShort
 
getResult(I, TTransactionServer.startShortTimeout_args) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Processor.startShortTimeout
 
getResult(I, TTransactionServer.startShortWithTimeout_args) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Processor.startShortWithTimeout
 
getResult(I, TTransactionServer.status_args) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Processor.status
 
getResult(I, TTransactionServer.truncateInvalidTx_args) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Processor.truncateInvalidTx
 
getResult(I, TTransactionServer.truncateInvalidTxBefore_args) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Processor.truncateInvalidTxBefore
 
getRow() - Method in class org.apache.tephra.AbstractTransactionAwareTable.ActionChange
 
getRowOrBefore(byte[], byte[]) - Method in class org.apache.tephra.hbase.TransactionAwareHTable
 
getRunnable(AbstractNonblockingServer.FrameBuffer) - Method in class org.apache.thrift.server.TThreadedSelectorServerWithFix
 
getScanner(Scan) - Method in class org.apache.tephra.hbase.TransactionAwareHTable
 
getScanner(byte[]) - Method in class org.apache.tephra.hbase.TransactionAwareHTable
 
getScanner(byte[], byte[]) - Method in class org.apache.tephra.hbase.TransactionAwareHTable
 
getSelectorThreads() - Method in class org.apache.thrift.server.TThreadedSelectorServerWithFix.Args
 
getSessionId() - Method in class org.apache.tephra.zookeeper.TephraZKClientService
 
getSingleNodeModules() - Method in class org.apache.tephra.runtime.DiscoveryModules
 
getSingleNodeModules() - Method in class org.apache.tephra.runtime.TransactionModules
 
getSnapshot(AsyncMethodCallback<TTransactionServer.AsyncClient.getSnapshot_call>) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.AsyncClient
 
getSnapshot(AsyncMethodCallback<TTransactionServer.AsyncClient.getSnapshot_call>) - Method in interface org.apache.tephra.distributed.thrift.TTransactionServer.AsyncIface
 
getSnapshot() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Client
 
getSnapshot() - Method in interface org.apache.tephra.distributed.thrift.TTransactionServer.Iface
 
getSnapshot() - Method in class org.apache.tephra.distributed.TransactionServiceThriftHandler
 
getSnapshot() - Method in class org.apache.tephra.TransactionManager
 
getSnapshotConfiguration() - Method in class org.apache.tephra.coprocessor.TransactionStateCache
 
getSnapshotInputStream() - Method in class org.apache.tephra.distributed.TransactionServiceClient
 
getSnapshotInputStream() - Method in class org.apache.tephra.inmemory.DetachedTxSystemClient
 
getSnapshotInputStream() - Method in class org.apache.tephra.inmemory.InMemoryTxSystemClient
 
getSnapshotInputStream() - Method in class org.apache.tephra.inmemory.MinimalTxSystemClient
 
getSnapshotInputStream() - Method in interface org.apache.tephra.TransactionSystemClient
Retrieves the state of the transaction manager and send it as a stream.
getSnapshotStream() - Method in class org.apache.tephra.distributed.TransactionServiceThriftClient
 
getState() - Method in class co.cask.tephra.persist.TransactionEdit
Deprecated.
Returns the type of state change represented.
getState() - Method in class org.apache.tephra.persist.TransactionEdit
Returns the type of state change represented.
getStopTimeoutUnit() - Method in class org.apache.thrift.server.TThreadedSelectorServerWithFix.Args
 
getStopTimeoutVal() - Method in class org.apache.thrift.server.TThreadedSelectorServerWithFix.Args
 
getSuccess() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_result
 
getSuccess() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_result
 
getSuccess() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_result
 
getSuccess() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.getSnapshot_result
 
getSuccess() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidTxSize_result
 
getSuccess() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startLong_result
 
getSuccess() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShort_result
 
getSuccess() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortTimeout_result
 
getSuccess() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_result
 
getSuccess() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.status_result
 
getSuccess() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTx_result
 
getSuccess() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_result
 
getTableDescriptor() - Method in class org.apache.tephra.hbase.TransactionAwareHTable
 
getTableKey() - Method in class org.apache.tephra.AbstractTransactionAwareTable
Returns the table name to use as a key prefix for the transaction change set.
getTableKey() - Method in class org.apache.tephra.hbase.TransactionAwareHTable
 
getTableName() - Method in class org.apache.tephra.hbase.TransactionAwareHTable
 
getThriftClient() - Method in class org.apache.tephra.distributed.CloseableThriftClient
 
getThriftFieldId() - Method in enum org.apache.tephra.distributed.thrift.TBoolean._Fields
 
getThriftFieldId() - Method in enum org.apache.tephra.distributed.thrift.TGenericException._Fields
 
getThriftFieldId() - Method in enum org.apache.tephra.distributed.thrift.TInvalidTruncateTimeException._Fields
 
getThriftFieldId() - Method in enum org.apache.tephra.distributed.thrift.TTransaction._Fields
 
getThriftFieldId() - Method in enum org.apache.tephra.distributed.thrift.TTransactionCouldNotTakeSnapshotException._Fields
 
getThriftFieldId() - Method in enum org.apache.tephra.distributed.thrift.TTransactionNotInProgressException._Fields
 
getThriftFieldId() - Method in enum org.apache.tephra.distributed.thrift.TTransactionServer.abortTx_args._Fields
 
getThriftFieldId() - Method in enum org.apache.tephra.distributed.thrift.TTransactionServer.abortTx_result._Fields
 
getThriftFieldId() - Method in enum org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_args._Fields
 
getThriftFieldId() - Method in enum org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_result._Fields
 
getThriftFieldId() - Method in enum org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_args._Fields
 
getThriftFieldId() - Method in enum org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_result._Fields
 
getThriftFieldId() - Method in enum org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_args._Fields
 
getThriftFieldId() - Method in enum org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_result._Fields
 
getThriftFieldId() - Method in enum org.apache.tephra.distributed.thrift.TTransactionServer.getSnapshot_args._Fields
 
getThriftFieldId() - Method in enum org.apache.tephra.distributed.thrift.TTransactionServer.getSnapshot_result._Fields
 
getThriftFieldId() - Method in enum org.apache.tephra.distributed.thrift.TTransactionServer.invalidateTx_args._Fields
 
getThriftFieldId() - Method in enum org.apache.tephra.distributed.thrift.TTransactionServer.invalidateTx_result._Fields
 
getThriftFieldId() - Method in enum org.apache.tephra.distributed.thrift.TTransactionServer.invalidTxSize_args._Fields
 
getThriftFieldId() - Method in enum org.apache.tephra.distributed.thrift.TTransactionServer.invalidTxSize_result._Fields
 
getThriftFieldId() - Method in enum org.apache.tephra.distributed.thrift.TTransactionServer.resetState_args._Fields
 
getThriftFieldId() - Method in enum org.apache.tephra.distributed.thrift.TTransactionServer.resetState_result._Fields
 
getThriftFieldId() - Method in enum org.apache.tephra.distributed.thrift.TTransactionServer.startLong_args._Fields
 
getThriftFieldId() - Method in enum org.apache.tephra.distributed.thrift.TTransactionServer.startLong_result._Fields
 
getThriftFieldId() - Method in enum org.apache.tephra.distributed.thrift.TTransactionServer.startShort_args._Fields
 
getThriftFieldId() - Method in enum org.apache.tephra.distributed.thrift.TTransactionServer.startShort_result._Fields
 
getThriftFieldId() - Method in enum org.apache.tephra.distributed.thrift.TTransactionServer.startShortTimeout_args._Fields
 
getThriftFieldId() - Method in enum org.apache.tephra.distributed.thrift.TTransactionServer.startShortTimeout_result._Fields
 
getThriftFieldId() - Method in enum org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_args._Fields
 
getThriftFieldId() - Method in enum org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_result._Fields
 
getThriftFieldId() - Method in enum org.apache.tephra.distributed.thrift.TTransactionServer.status_args._Fields
 
getThriftFieldId() - Method in enum org.apache.tephra.distributed.thrift.TTransactionServer.status_result._Fields
 
getThriftFieldId() - Method in enum org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTx_args._Fields
 
getThriftFieldId() - Method in enum org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTx_result._Fields
 
getThriftFieldId() - Method in enum org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_args._Fields
 
getThriftFieldId() - Method in enum org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_result._Fields
 
getTime() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_args
 
getTime() - Method in class org.apache.tephra.hbase.txprune.TimeRegions
 
getTimeout() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortTimeout_args
 
getTimeout() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_args
 
getTimestamp() - Method in class org.apache.tephra.persist.AbstractTransactionLog
 
getTimestamp() - Method in interface org.apache.tephra.persist.TransactionLog
 
getTimestamp() - Method in class org.apache.tephra.persist.TransactionSnapshot
 
getTimestamp() - Method in interface org.apache.tephra.persist.TransactionVisibilityState
Returns the timestamp from when this snapshot was created.
getTimestamp(long) - Static method in class org.apache.tephra.util.TxUtils
Returns the timestamp at which the given transaction id was generated.
getTimestampForTTL(long) - Static method in class org.apache.tephra.util.TxUtils
Returns the timestamp for calculating time to live for the given cell timestamp.
getTransactionalRegions() - Method in class org.apache.tephra.hbase.txprune.HBaseTransactionPruningPlugin
 
getTransactionAwareName() - Method in class org.apache.tephra.AbstractTransactionAwareTable
 
getTransactionAwareName() - Method in interface org.apache.tephra.TransactionAware
Used for error reporting.
getTransactionFilter(Transaction, ScanType, Filter) - Method in class org.apache.tephra.hbase.coprocessor.TransactionProcessor
Derived classes can override this method to customize the filter used to return data visible for the current transaction.
getTransactionId() - Method in class org.apache.tephra.distributed.thrift.TTransaction
 
getTransactionId() - Method in class org.apache.tephra.Transaction
Returns the initial write pointer assigned to the transaction.
getTransactionManager() - Method in class org.apache.tephra.distributed.TransactionService
 
getTransactionStateCacheSupplier(RegionCoprocessorEnvironment) - Method in class org.apache.tephra.hbase.coprocessor.TransactionProcessor
 
getTransactionStateStorage() - Method in class org.apache.tephra.TransactionManager
 
getTransactionType() - Method in enum org.apache.tephra.TransactionManager.InProgressType
 
getTruncateInvalidTx() - Method in class co.cask.tephra.persist.TransactionEdit
Deprecated.
Returns the transaction ids to be removed from invalid transaction list.
getTruncateInvalidTx() - Method in class org.apache.tephra.persist.TransactionEdit
Returns the transaction ids to be removed from invalid transaction list.
getTruncateInvalidTxTime() - Method in class co.cask.tephra.persist.TransactionEdit
Deprecated.
Returns the time until which the invalid transactions need to be truncated from invalid transaction list.
getTruncateInvalidTxTime() - Method in class org.apache.tephra.persist.TransactionEdit
Returns the time until which the invalid transactions need to be truncated from invalid transaction list.
getTx() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.abortTx_args
 
getTx() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_args
 
getTx() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_args
 
getTx() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_args
 
getTx() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidateTx_args
 
getTxChanges() - Method in class org.apache.tephra.AbstractTransactionAwareTable
 
getTxChanges() - Method in interface org.apache.tephra.TransactionAware
 
getTxExpirationFromWritePointer(long, long) - Static method in class org.apache.tephra.TransactionManager
 
getTxns() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTx_args
 
getTxnsIterator() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTx_args
 
getTxnsSize() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTx_args
 
getType() - Method in class co.cask.tephra.persist.TransactionEdit
Deprecated.
Returns the transaction type.
getType() - Method in class org.apache.tephra.distributed.thrift.TTransaction
 
getType() - Method in class org.apache.tephra.persist.TransactionEdit
Returns the transaction type.
getType() - Method in class org.apache.tephra.Transaction
 
getType() - Method in class org.apache.tephra.TransactionManager.InProgressTx
 
getValue() - Method in enum org.apache.tephra.distributed.thrift.TTransactionType
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum org.apache.tephra.distributed.thrift.TVisibilityLevel
Get the integer value of this enum value, as defined in the Thrift IDL.
getVersion() - Method in class org.apache.tephra.snapshot.DefaultSnapshotCodec
Deprecated.
 
getVersion() - Method in interface org.apache.tephra.snapshot.SnapshotCodec
 
getVersion() - Method in class org.apache.tephra.snapshot.SnapshotCodecProvider
 
getVersion() - Method in class org.apache.tephra.snapshot.SnapshotCodecV2
 
getVersion() - Method in class org.apache.tephra.snapshot.SnapshotCodecV3
 
getVersion() - Method in class org.apache.tephra.snapshot.SnapshotCodecV4
 
getVersionString() - Static method in class org.apache.tephra.util.HBaseVersion
Returns the full version string for the currently loaded HBase library.
getVisibilityFilter(Transaction, Map<byte[], Long>, boolean, ScanType) - Static method in class org.apache.tephra.hbase.coprocessor.TransactionFilters
Creates a new Filter for returning data only from visible transactions.
getVisibilityFilter(Transaction, Map<byte[], Long>, boolean, ScanType, Filter) - Static method in class org.apache.tephra.hbase.coprocessor.TransactionFilters
Creates a new Filter for returning data only from visible transactions.
getVisibilityLevel() - Method in class org.apache.tephra.distributed.thrift.TTransaction
 
getVisibilityLevel() - Method in class org.apache.tephra.Transaction
Returns the currently set visibility level.
getVisibilityUpperBound() - Method in class co.cask.tephra.persist.TransactionEdit
Deprecated.
 
getVisibilityUpperBound() - Method in class org.apache.tephra.persist.TransactionEdit
 
getVisibilityUpperBound() - Method in class org.apache.tephra.persist.TransactionSnapshot
 
getVisibilityUpperBound() - Method in interface org.apache.tephra.persist.TransactionVisibilityState
 
getVisibilityUpperBound() - Method in class org.apache.tephra.Transaction
 
getVisibilityUpperBound() - Method in class org.apache.tephra.TransactionManager.InProgressTx
 
getWorkerThreads() - Method in class org.apache.thrift.server.TThreadedSelectorServerWithFix.Args
 
getWriteBufferSize() - Method in class org.apache.tephra.hbase.TransactionAwareHTable
 
getWritePointer() - Method in class co.cask.tephra.persist.TransactionEdit
Deprecated.
Returns the transaction write pointer assigned for the state change.
getWritePointer() - Method in class org.apache.tephra.distributed.thrift.TTransaction
 
getWritePointer() - Method in class org.apache.tephra.persist.TransactionEdit
Returns the transaction write pointer assigned for the state change.
getWritePointer() - Method in class org.apache.tephra.persist.TransactionSnapshot
 
getWritePointer() - Method in interface org.apache.tephra.persist.TransactionVisibilityState
Returns the next write pointer at the time of the snapshot.
getWritePointer() - Method in class org.apache.tephra.Transaction
Returns the write pointer to be used in persisting any changes.
getZooKeeperSupplier() - Method in class org.apache.tephra.zookeeper.TephraZKClientService
 
gracefullyShutdownInvokerPool() - Method in class org.apache.thrift.server.TThreadedSelectorServerWithFix
 

H

hasExcludes() - Method in class org.apache.tephra.Transaction
 
hasFilterRow() - Method in class org.apache.tephra.hbase.coprocessor.CellSkipFilter
 
hasFilterRow() - Method in class org.apache.tephra.hbase.coprocessor.TransactionVisibilityFilter
 
hashCode() - Method in class co.cask.tephra.persist.TransactionEdit
Deprecated.
 
hashCode() - Method in class org.apache.tephra.AbstractTransactionAwareTable.ActionChange
 
hashCode() - Method in class org.apache.tephra.ChangeId
 
hashCode() - Method in class org.apache.tephra.distributed.thrift.TBoolean
 
hashCode() - Method in exception org.apache.tephra.distributed.thrift.TGenericException
 
hashCode() - Method in exception org.apache.tephra.distributed.thrift.TInvalidTruncateTimeException
 
hashCode() - Method in class org.apache.tephra.distributed.thrift.TTransaction
 
hashCode() - Method in exception org.apache.tephra.distributed.thrift.TTransactionCouldNotTakeSnapshotException
 
hashCode() - Method in exception org.apache.tephra.distributed.thrift.TTransactionNotInProgressException
 
hashCode() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.abortTx_args
 
hashCode() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.abortTx_result
 
hashCode() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_args
 
hashCode() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_result
 
hashCode() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_args
 
hashCode() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_result
 
hashCode() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_args
 
hashCode() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_result
 
hashCode() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.getSnapshot_args
 
hashCode() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.getSnapshot_result
 
hashCode() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidateTx_args
 
hashCode() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidateTx_result
 
hashCode() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidTxSize_args
 
hashCode() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidTxSize_result
 
hashCode() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.resetState_args
 
hashCode() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.resetState_result
 
hashCode() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startLong_args
 
hashCode() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startLong_result
 
hashCode() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShort_args
 
hashCode() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShort_result
 
hashCode() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortTimeout_args
 
hashCode() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortTimeout_result
 
hashCode() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_args
 
hashCode() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_result
 
hashCode() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.status_args
 
hashCode() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.status_result
 
hashCode() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTx_args
 
hashCode() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTx_result
 
hashCode() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_args
 
hashCode() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_result
 
hashCode() - Method in class org.apache.tephra.hbase.txprune.TimeRegions
 
hashCode() - Method in class org.apache.tephra.persist.TransactionEdit
 
hashCode() - Method in class org.apache.tephra.persist.TransactionSnapshot
 
hashCode() - Method in class org.apache.tephra.TransactionManager.InProgressTx
 
hashCode() - Method in class org.apache.tephra.txprune.RegionPruneInfo
 
HBase10ConfigurationProvider - Class in org.apache.tephra.hbase
HBase 1.0 version of ConfigurationProvider.
HBase10ConfigurationProvider() - Constructor for class org.apache.tephra.hbase.HBase10ConfigurationProvider
 
HBase11ConfigurationProvider - Class in org.apache.tephra.hbase
HBase 1.1 version of ConfigurationProvider.
HBase11ConfigurationProvider() - Constructor for class org.apache.tephra.hbase.HBase11ConfigurationProvider
 
HBase96ConfigurationProvider - Class in org.apache.tephra.hbase
HBase 0.96 version of ConfigurationProvider.
HBase96ConfigurationProvider() - Constructor for class org.apache.tephra.hbase.HBase96ConfigurationProvider
 
HBase98ConfigurationProvider - Class in org.apache.tephra.hbase
HBase 0.98 version of ConfigurationProvider.
HBase98ConfigurationProvider() - Constructor for class org.apache.tephra.hbase.HBase98ConfigurationProvider
 
hBaseAdmin - Variable in class org.apache.tephra.hbase.txprune.HBaseTransactionPruningPlugin
 
HBaseTransactionPruningPlugin - Class in org.apache.tephra.hbase.txprune
Default implementation of the TransactionPruningPlugin for HBase.
HBaseTransactionPruningPlugin() - Constructor for class org.apache.tephra.hbase.txprune.HBaseTransactionPruningPlugin
 
HBaseVersion - Class in org.apache.tephra.util
Detects the currently loaded HBase version.
HBaseVersion() - Constructor for class org.apache.tephra.util.HBaseVersion
 
HBaseVersion.Version - Enum in org.apache.tephra.util
Represents the major version of the HBase library that is currently loaded.
HBaseVersion.VersionNumber - Class in org.apache.tephra.util
Utility class to parse apart version number components.
HBaseVersionSpecificFactory<T> - Class in org.apache.tephra.util
Common class factory behavior for classes which need specific implementations depending on HBase versions.
HBaseVersionSpecificFactory() - Constructor for class org.apache.tephra.util.HBaseVersionSpecificFactory
 
HDFSTransactionLog - Class in org.apache.tephra.persist
Allows reading from and writing to a transaction write-ahead log stored in HDFS.
HDFSTransactionLog(FileSystem, Configuration, Path, long, MetricsCollector) - Constructor for class org.apache.tephra.persist.HDFSTransactionLog
Creates a new HDFS-backed write-ahead log for storing transaction state.
HDFSTransactionLogReaderSupplier - Class in org.apache.tephra.persist
Provides the correct version of TransactionLogReader, based on the log's version metadata, to read HDFS Transaction Logs.
HDFSTransactionLogReaderSupplier(SequenceFile.Reader) - Constructor for class org.apache.tephra.persist.HDFSTransactionLogReaderSupplier
 
HDFSTransactionLogReaderV1 - Class in org.apache.tephra.persist
TransactionLogReader that can read v1 (default) version of Transaction logs.
HDFSTransactionLogReaderV1(SequenceFile.Reader) - Constructor for class org.apache.tephra.persist.HDFSTransactionLogReaderV1
 
HDFSTransactionLogReaderV2 - Class in org.apache.tephra.persist
TransactionLogReader that can read v2 version of Transaction logs.
HDFSTransactionLogReaderV2(SequenceFile.Reader) - Constructor for class org.apache.tephra.persist.HDFSTransactionLogReaderV2
 
HDFSTransactionLogReaderV3 - Class in org.apache.tephra.persist
TransactionLogReader that can read v3 version of Transaction logs.
HDFSTransactionLogReaderV3(SequenceFile.Reader) - Constructor for class org.apache.tephra.persist.HDFSTransactionLogReaderV3
 
HDFSTransactionStateStorage - Class in org.apache.tephra.persist
Handles persistence of transaction snapshot and logs to a directory in HDFS.
HDFSTransactionStateStorage(Configuration, SnapshotCodecProvider, MetricsCollector) - Constructor for class org.apache.tephra.persist.HDFSTransactionStateStorage
 
HDFSUtil - Class in org.apache.tephra.persist
Utility for handling HDFS file lease recovery.
HDFSUtil() - Constructor for class org.apache.tephra.persist.HDFSUtil
 
histogram(String, int) - Method in class org.apache.tephra.metrics.DefaultMetricsCollector
 
histogram(String, int) - Method in interface org.apache.tephra.metrics.MetricsCollector
Report a metric calculating the distribution of the value.
histogram(String, int) - Method in class org.apache.tephra.metrics.TxMetricsCollector
 

I

increment(Increment) - Method in class org.apache.tephra.hbase.TransactionAwareHTable
 
incrementColumnValue(byte[], byte[], byte[], long) - Method in class org.apache.tephra.hbase.TransactionAwareHTable
 
incrementColumnValue(byte[], byte[], byte[], long, Durability) - Method in class org.apache.tephra.hbase.TransactionAwareHTable
 
incrementColumnValue(byte[], byte[], byte[], long, boolean) - Method in class org.apache.tephra.hbase.TransactionAwareHTable
 
init() - Method in class org.apache.tephra.distributed.TransactionServiceThriftHandler
 
init() - Method in class org.apache.tephra.examples.BalanceBooks
Sets up common resources required by all clients.
init() - Method in class org.apache.tephra.persist.AbstractTransactionLog
Initializes the log file, opening a file writer.
init() - Method in interface org.apache.tephra.rpc.RPCServiceHandler
 
init(String[]) - Method in class org.apache.tephra.TransactionServiceMain
Invoked by jsvc to initialize the program.
initialize() - Method in class org.apache.tephra.distributed.AbstractClientProvider
 
initialize() - Method in interface org.apache.tephra.distributed.ThriftClientProvider
Initialize the provider.
initialize(Configuration) - Method in class org.apache.tephra.hbase.txprune.HBaseTransactionPruningPlugin
 
initialize(Configuration) - Method in class org.apache.tephra.hbase.txprune.InvalidListPruningDebug
Initialize the Invalid List Debug Tool.
initialize(Configuration) - Method in interface org.apache.tephra.txprune.TransactionPruningPlugin
Called once when the Transaction Service starts up.
initialized - Variable in class org.apache.tephra.distributed.AbstractClientProvider
 
initializePruneState(RegionCoprocessorEnvironment) - Method in class org.apache.tephra.hbase.coprocessor.TransactionProcessor
Refresh the properties related to transaction pruning.
InMemoryTransactionService - Class in org.apache.tephra.inmemory
Transaction server that manages transaction data for the Reactor.
InMemoryTransactionService(Configuration, DiscoveryService, Provider<TransactionManager>) - Constructor for class org.apache.tephra.inmemory.InMemoryTransactionService
 
InMemoryTxSystemClient - Class in org.apache.tephra.inmemory
 
InMemoryTxSystemClient(TransactionManager) - Constructor for class org.apache.tephra.inmemory.InMemoryTxSystemClient
 
inProgress - Variable in class org.apache.tephra.distributed.thrift.TTransaction
 
instance - Static variable in class org.apache.tephra.coprocessor.TransactionStateCacheSupplier
 
INSTANCE - Static variable in class org.apache.tephra.NoRetryStrategy
 
internalStop() - Method in class org.apache.tephra.distributed.TransactionService
 
invalidate(long) - Method in class org.apache.tephra.distributed.TransactionServiceClient
 
invalidate(long) - Method in class org.apache.tephra.distributed.TransactionServiceThriftClient
 
invalidate(long) - Method in class org.apache.tephra.inmemory.DetachedTxSystemClient
 
invalidate(long) - Method in class org.apache.tephra.inmemory.InMemoryTxSystemClient
 
invalidate(long) - Method in class org.apache.tephra.inmemory.MinimalTxSystemClient
 
invalidate(long) - Method in class org.apache.tephra.TransactionManager
 
invalidate(long) - Method in interface org.apache.tephra.TransactionSystemClient
Makes transaction invalid.
invalidateTx(long, AsyncMethodCallback<TTransactionServer.AsyncClient.invalidateTx_call>) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.AsyncClient
 
invalidateTx(long, AsyncMethodCallback<TTransactionServer.AsyncClient.invalidateTx_call>) - Method in interface org.apache.tephra.distributed.thrift.TTransactionServer.AsyncIface
 
invalidateTx(long) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Client
 
invalidateTx(long) - Method in interface org.apache.tephra.distributed.thrift.TTransactionServer.Iface
 
invalidateTx(long) - Method in class org.apache.tephra.distributed.TransactionServiceThriftHandler
 
InvalidListPruningDebug - Class in org.apache.tephra.hbase.txprune
Invalid List Pruning Debug Tool.
InvalidListPruningDebug() - Constructor for class org.apache.tephra.hbase.txprune.InvalidListPruningDebug
 
invalids - Variable in class org.apache.tephra.distributed.thrift.TTransaction
 
InvalidTruncateTimeException - Exception in org.apache.tephra
Thrown when truncate invalid list is called with a time, and when there are in-progress transactions that were started before the given time.
InvalidTruncateTimeException(String) - Constructor for exception org.apache.tephra.InvalidTruncateTimeException
 
InvalidTxList - Class in org.apache.tephra.manager
This is an internal class used by the TransactionManager to store invalid transaction ids.
InvalidTxList() - Constructor for class org.apache.tephra.manager.InvalidTxList
 
invalidTxSize(AsyncMethodCallback<TTransactionServer.AsyncClient.invalidTxSize_call>) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.AsyncClient
 
invalidTxSize(AsyncMethodCallback<TTransactionServer.AsyncClient.invalidTxSize_call>) - Method in interface org.apache.tephra.distributed.thrift.TTransactionServer.AsyncIface
 
invalidTxSize() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Client
 
invalidTxSize() - Method in interface org.apache.tephra.distributed.thrift.TTransactionServer.Iface
 
invalidTxSize() - Method in class org.apache.tephra.distributed.TransactionServiceThriftHandler
 
ioThreads - Variable in class org.apache.tephra.inmemory.InMemoryTransactionService
 
isAlive() - Method in class org.apache.tephra.hbase.txprune.PruneUpperBoundWriter
 
isAutoFlush() - Method in class org.apache.tephra.hbase.TransactionAwareHTable
 
isCheckpoint(long) - Method in class org.apache.tephra.Transaction
Returns true if the the given version corresponds to one of the checkpoint versions in the current transaction.
isClosed() - Method in class org.apache.tephra.persist.AbstractTransactionLog
 
isCurrentWrite(long) - Method in class org.apache.tephra.Transaction
Returns whether the given version was written by the current transaction.
isEmpty() - Method in class org.apache.tephra.manager.InvalidTxList
 
isExcluded(long) - Method in class org.apache.tephra.Transaction
Returns true if the given version is present in one of the arrays of excluded versions (in-progress and invalid transactions).
isFamilyEssential(byte[]) - Method in class org.apache.tephra.hbase.coprocessor.CellSkipFilter
 
isFamilyEssential(byte[]) - Method in class org.apache.tephra.hbase.coprocessor.TransactionVisibilityFilter
 
isInProgress(long) - Method in class org.apache.tephra.Transaction
Returns true if the given version corresponds to a transaction that was in-progress at the time this transaction started.
isLongRunning() - Method in class org.apache.tephra.TransactionManager.InProgressTx
 
isOneway() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Processor.abortTx
 
isOneway() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Processor.canCommitTx
 
isOneway() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Processor.checkpoint
 
isOneway() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Processor.commitTx
 
isOneway() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Processor.getSnapshot
 
isOneway() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Processor.invalidateTx
 
isOneway() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Processor.invalidTxSize
 
isOneway() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Processor.resetState
 
isOneway() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Processor.startLong
 
isOneway() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Processor.startShort
 
isOneway() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Processor.startShortTimeout
 
isOneway() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Processor.startShortWithTimeout
 
isOneway() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Processor.status
 
isOneway() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Processor.truncateInvalidTx
 
isOneway() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Processor.truncateInvalidTxBefore
 
isPreExistingVersion(long) - Static method in class org.apache.tephra.util.TxUtils
Returns true if version was written before table was converted into transactional table, false otherwise.
isSet(TBoolean._Fields) - Method in class org.apache.tephra.distributed.thrift.TBoolean
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TGenericException._Fields) - Method in exception org.apache.tephra.distributed.thrift.TGenericException
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TInvalidTruncateTimeException._Fields) - Method in exception org.apache.tephra.distributed.thrift.TInvalidTruncateTimeException
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TTransaction._Fields) - Method in class org.apache.tephra.distributed.thrift.TTransaction
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TTransactionCouldNotTakeSnapshotException._Fields) - Method in exception org.apache.tephra.distributed.thrift.TTransactionCouldNotTakeSnapshotException
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TTransactionNotInProgressException._Fields) - Method in exception org.apache.tephra.distributed.thrift.TTransactionNotInProgressException
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TTransactionServer.abortTx_args._Fields) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.abortTx_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TTransactionServer.abortTx_result._Fields) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.abortTx_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TTransactionServer.canCommitTx_args._Fields) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TTransactionServer.canCommitTx_result._Fields) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TTransactionServer.checkpoint_args._Fields) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TTransactionServer.checkpoint_result._Fields) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TTransactionServer.commitTx_args._Fields) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TTransactionServer.commitTx_result._Fields) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TTransactionServer.getSnapshot_args._Fields) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.getSnapshot_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TTransactionServer.getSnapshot_result._Fields) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.getSnapshot_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TTransactionServer.invalidateTx_args._Fields) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidateTx_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TTransactionServer.invalidateTx_result._Fields) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidateTx_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TTransactionServer.invalidTxSize_args._Fields) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidTxSize_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TTransactionServer.invalidTxSize_result._Fields) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidTxSize_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TTransactionServer.resetState_args._Fields) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.resetState_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TTransactionServer.resetState_result._Fields) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.resetState_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TTransactionServer.startLong_args._Fields) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startLong_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TTransactionServer.startLong_result._Fields) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startLong_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TTransactionServer.startShort_args._Fields) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShort_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TTransactionServer.startShort_result._Fields) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShort_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TTransactionServer.startShortTimeout_args._Fields) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortTimeout_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TTransactionServer.startShortTimeout_result._Fields) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortTimeout_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TTransactionServer.startShortWithTimeout_args._Fields) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TTransactionServer.startShortWithTimeout_result._Fields) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TTransactionServer.status_args._Fields) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.status_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TTransactionServer.status_result._Fields) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.status_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TTransactionServer.truncateInvalidTx_args._Fields) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTx_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TTransactionServer.truncateInvalidTx_result._Fields) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTx_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TTransactionServer.truncateInvalidTxBefore_args._Fields) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TTransactionServer.truncateInvalidTxBefore_result._Fields) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSetChanges() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_args
Returns true if field changes is set (has been assigned a value) and false otherwise
isSetCheckpointWritePointers() - Method in class org.apache.tephra.distributed.thrift.TTransaction
Returns true if field checkpointWritePointers is set (has been assigned a value) and false otherwise
isSetE() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.getSnapshot_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetE() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_result
Returns true if field e is set (has been assigned a value) and false otherwise
isSetFirstShort() - Method in class org.apache.tephra.distributed.thrift.TTransaction
Returns true if field firstShort is set (has been assigned a value) and false otherwise
isSetInProgress() - Method in class org.apache.tephra.distributed.thrift.TTransaction
Returns true if field inProgress is set (has been assigned a value) and false otherwise
isSetInvalids() - Method in class org.apache.tephra.distributed.thrift.TTransaction
Returns true if field invalids is set (has been assigned a value) and false otherwise
isSetMessage() - Method in exception org.apache.tephra.distributed.thrift.TGenericException
Returns true if field message is set (has been assigned a value) and false otherwise
isSetMessage() - Method in exception org.apache.tephra.distributed.thrift.TInvalidTruncateTimeException
Returns true if field message is set (has been assigned a value) and false otherwise
isSetMessage() - Method in exception org.apache.tephra.distributed.thrift.TTransactionCouldNotTakeSnapshotException
Returns true if field message is set (has been assigned a value) and false otherwise
isSetMessage() - Method in exception org.apache.tephra.distributed.thrift.TTransactionNotInProgressException
Returns true if field message is set (has been assigned a value) and false otherwise
isSetOriginalExceptionClass() - Method in exception org.apache.tephra.distributed.thrift.TGenericException
Returns true if field originalExceptionClass is set (has been assigned a value) and false otherwise
isSetReadPointer() - Method in class org.apache.tephra.distributed.thrift.TTransaction
Returns true if field readPointer is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.getSnapshot_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidateTx_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidTxSize_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startLong_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShort_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortTimeout_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.status_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTx_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetTime() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_args
Returns true if field time is set (has been assigned a value) and false otherwise
isSetTimeout() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortTimeout_args
Returns true if field timeout is set (has been assigned a value) and false otherwise
isSetTimeout() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_args
Returns true if field timeout is set (has been assigned a value) and false otherwise
isSetTransactionId() - Method in class org.apache.tephra.distributed.thrift.TTransaction
Returns true if field transactionId is set (has been assigned a value) and false otherwise
isSetTx() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.abortTx_args
Returns true if field tx is set (has been assigned a value) and false otherwise
isSetTx() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_args
Returns true if field tx is set (has been assigned a value) and false otherwise
isSetTx() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_args
Returns true if field tx is set (has been assigned a value) and false otherwise
isSetTx() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_args
Returns true if field tx is set (has been assigned a value) and false otherwise
isSetTx() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidateTx_args
Returns true if field tx is set (has been assigned a value) and false otherwise
isSetTxns() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTx_args
Returns true if field txns is set (has been assigned a value) and false otherwise
isSetType() - Method in class org.apache.tephra.distributed.thrift.TTransaction
Returns true if field type is set (has been assigned a value) and false otherwise
isSetValue() - Method in class org.apache.tephra.distributed.thrift.TBoolean
Returns true if field value is set (has been assigned a value) and false otherwise
isSetVisibilityLevel() - Method in class org.apache.tephra.distributed.thrift.TTransaction
Returns true if field visibilityLevel is set (has been assigned a value) and false otherwise
isSetWritePointer() - Method in class org.apache.tephra.distributed.thrift.TTransaction
Returns true if field writePointer is set (has been assigned a value) and false otherwise
isSnapshot() - Method in class org.apache.tephra.util.HBaseVersion.VersionNumber
 
isSuccess() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidateTx_result
 
isTransactionalTable(HTableDescriptor) - Method in class org.apache.tephra.hbase.txprune.HBaseTransactionPruningPlugin
Returns whether the table is a transactional table.
isValid() - Method in class org.apache.tephra.distributed.TransactionServiceThriftClient
 
isValue() - Method in class org.apache.tephra.distributed.thrift.TBoolean
 
isVisible(long) - Method in class org.apache.tephra.Transaction
Returns whether or not the given version should be visible to the current transaction.

J

joinThreads() - Method in class org.apache.thrift.server.TThreadedSelectorServerWithFix
 

L

listLogs() - Method in class org.apache.tephra.persist.HDFSTransactionStateStorage
 
listLogs() - Method in class org.apache.tephra.persist.LocalFileTransactionStateStorage
 
listLogs() - Method in class org.apache.tephra.persist.NoOpTransactionStateStorage
 
listLogs() - Method in interface org.apache.tephra.persist.TransactionStateStorage
Returns the (non-qualified) names of available logs.
listSnapshots() - Method in class org.apache.tephra.persist.HDFSTransactionStateStorage
 
listSnapshots() - Method in class org.apache.tephra.persist.LocalFileTransactionStateStorage
 
listSnapshots() - Method in class org.apache.tephra.persist.NoOpTransactionStateStorage
 
listSnapshots() - Method in interface org.apache.tephra.persist.TransactionStateStorage
Returns the (non-qualified) names of available snapshots.
LocalFileTransactionLog - Class in org.apache.tephra.persist
Reads and writes transaction logs against files in the local filesystem.
LocalFileTransactionLog(File, long, MetricsCollector) - Constructor for class org.apache.tephra.persist.LocalFileTransactionLog
Creates a new transaction log using the given file instance.
LocalFileTransactionStateStorage - Class in org.apache.tephra.persist
Persists transaction snapshots and write-ahead logs to files on the local filesystem.
LocalFileTransactionStateStorage(Configuration, SnapshotCodecProvider, MetricsCollector) - Constructor for class org.apache.tephra.persist.LocalFileTransactionStateStorage
 
lock - Static variable in class org.apache.tephra.coprocessor.TransactionStateCacheSupplier
 
LOG - Static variable in class org.apache.tephra.hbase.txprune.HBaseTransactionPruningPlugin
 
logStatistics() - Method in class org.apache.tephra.TransactionManager
Called from the tx service every 10 seconds.

M

main(String[]) - Static method in class org.apache.tephra.distributed.TransactionServiceClient
Utility to be used for basic verification of transaction system availability and functioning
main(String[]) - Static method in class org.apache.tephra.examples.BalanceBooks
 
main(String[]) - Static method in class org.apache.tephra.hbase.txprune.InvalidListPruningDebug
 
main(String[]) - Static method in class org.apache.tephra.persist.HDFSTransactionStateStorage
Reads a transaction state snapshot or transaction log from HDFS and prints the entries to stdout.
main(String[]) - Static method in class org.apache.tephra.TransactionAdmin
 
main(String[]) - Static method in class org.apache.tephra.TransactionServiceMain
 
main(String[]) - Static method in class org.apache.tephra.util.HBaseVersion
Prints out the HBase HBaseVersion.Version enum value for the current version of HBase on the classpath.
makeRollbackOperation(Delete) - Method in class org.apache.tephra.hbase.TransactionAwareHTable
 
MAX_TX_PER_MS - Static variable in class org.apache.tephra.TxConstants
This is how many tx we allow per millisecond, if you care about the system for 100 years: Long.MAX_VALUE / (System.currentTimeMillis() + TimeUnit.DAYS.toMillis(365 * 100)) = (as of Feb 20, 2014) 2,028,653.
maxReadBufferBytes - Variable in class org.apache.tephra.inmemory.InMemoryTransactionService
 
message - Variable in exception org.apache.tephra.distributed.thrift.TGenericException
 
message - Variable in exception org.apache.tephra.distributed.thrift.TInvalidTruncateTimeException
 
message - Variable in exception org.apache.tephra.distributed.thrift.TTransactionCouldNotTakeSnapshotException
 
message - Variable in exception org.apache.tephra.distributed.thrift.TTransactionNotInProgressException
 
metaDataMap - Static variable in class org.apache.tephra.distributed.thrift.TBoolean
 
metaDataMap - Static variable in exception org.apache.tephra.distributed.thrift.TGenericException
 
metaDataMap - Static variable in exception org.apache.tephra.distributed.thrift.TInvalidTruncateTimeException
 
metaDataMap - Static variable in class org.apache.tephra.distributed.thrift.TTransaction
 
metaDataMap - Static variable in exception org.apache.tephra.distributed.thrift.TTransactionCouldNotTakeSnapshotException
 
metaDataMap - Static variable in exception org.apache.tephra.distributed.thrift.TTransactionNotInProgressException
 
metaDataMap - Static variable in class org.apache.tephra.distributed.thrift.TTransactionServer.abortTx_args
 
metaDataMap - Static variable in class org.apache.tephra.distributed.thrift.TTransactionServer.abortTx_result
 
metaDataMap - Static variable in class org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_args
 
metaDataMap - Static variable in class org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_result
 
metaDataMap - Static variable in class org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_args
 
metaDataMap - Static variable in class org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_result
 
metaDataMap - Static variable in class org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_args
 
metaDataMap - Static variable in class org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_result
 
metaDataMap - Static variable in class org.apache.tephra.distributed.thrift.TTransactionServer.getSnapshot_args
 
metaDataMap - Static variable in class org.apache.tephra.distributed.thrift.TTransactionServer.getSnapshot_result
 
metaDataMap - Static variable in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidateTx_args
 
metaDataMap - Static variable in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidateTx_result
 
metaDataMap - Static variable in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidTxSize_args
 
metaDataMap - Static variable in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidTxSize_result
 
metaDataMap - Static variable in class org.apache.tephra.distributed.thrift.TTransactionServer.resetState_args
 
metaDataMap - Static variable in class org.apache.tephra.distributed.thrift.TTransactionServer.resetState_result
 
metaDataMap - Static variable in class org.apache.tephra.distributed.thrift.TTransactionServer.startLong_args
 
metaDataMap - Static variable in class org.apache.tephra.distributed.thrift.TTransactionServer.startLong_result
 
metaDataMap - Static variable in class org.apache.tephra.distributed.thrift.TTransactionServer.startShort_args
 
metaDataMap - Static variable in class org.apache.tephra.distributed.thrift.TTransactionServer.startShort_result
 
metaDataMap - Static variable in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortTimeout_args
 
metaDataMap - Static variable in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortTimeout_result
 
metaDataMap - Static variable in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_args
 
metaDataMap - Static variable in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_result
 
metaDataMap - Static variable in class org.apache.tephra.distributed.thrift.TTransactionServer.status_args
 
metaDataMap - Static variable in class org.apache.tephra.distributed.thrift.TTransactionServer.status_result
 
metaDataMap - Static variable in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTx_args
 
metaDataMap - Static variable in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTx_result
 
metaDataMap - Static variable in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_args
 
metaDataMap - Static variable in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_result
 
MetricsCollector - Interface in org.apache.tephra.metrics
Basic API for Tephra to support system metrics.
MinimalTxSystemClient - Class in org.apache.tephra.inmemory
Dummy implementation of TxSystemClient.
MinimalTxSystemClient() - Constructor for class org.apache.tephra.inmemory.MinimalTxSystemClient
 
mutateRow(RowMutations) - Method in class org.apache.tephra.hbase.TransactionAwareHTable
 

N

newClient() - Method in class org.apache.tephra.distributed.AbstractClientProvider
 
newClient(int) - Method in class org.apache.tephra.distributed.AbstractClientProvider
 
newRetryStrategy() - Method in class org.apache.tephra.distributed.RetryNTimes.Provider
 
newRetryStrategy() - Method in interface org.apache.tephra.distributed.RetryStrategyProvider
Provides a new instance of a retry strategy.
newRetryStrategy() - Method in class org.apache.tephra.distributed.RetryWithBackoff.Provider
 
next() - Method in class org.apache.tephra.persist.HDFSTransactionLogReaderV1
 
next(TransactionEdit) - Method in class org.apache.tephra.persist.HDFSTransactionLogReaderV1
 
next() - Method in class org.apache.tephra.persist.HDFSTransactionLogReaderV2
 
next(TransactionEdit) - Method in class org.apache.tephra.persist.HDFSTransactionLogReaderV2
 
next() - Method in class org.apache.tephra.persist.HDFSTransactionLogReaderV3
 
next(TransactionEdit) - Method in class org.apache.tephra.persist.HDFSTransactionLogReaderV3
 
next() - Method in interface org.apache.tephra.persist.TransactionLogReader
Returns the next TransactionEdit from the log file, based on the current position, or null if the end of the file has been reached.
next(TransactionEdit) - Method in interface org.apache.tephra.persist.TransactionLogReader
Populates reuse with the next TransactionEdit, based on the reader's current position in the log file.
nextRetry(TransactionFailureException, int) - Method in class org.apache.tephra.NoRetryStrategy
 
nextRetry(TransactionFailureException, int) - Method in class org.apache.tephra.RetryOnConflictStrategy
 
nextRetry(TransactionFailureException, int) - Method in interface org.apache.tephra.RetryStrategy
Returns the number of milliseconds to wait before retrying the operation.
nextThread() - Method in class org.apache.thrift.server.TThreadedSelectorServerWithFix.SelectorThreadLoadBalancer
 
NO_TX_IN_PROGRESS - Static variable in class org.apache.tephra.Transaction
 
NoOpTransactionStateStorage - Class in org.apache.tephra.persist
Minimal TransactionStateStorage implementation that does nothing, i.e.
NoOpTransactionStateStorage(SnapshotCodecProvider) - Constructor for class org.apache.tephra.persist.NoOpTransactionStateStorage
 
noRetries() - Static method in class org.apache.tephra.RetryStrategies
 
NoRetryStrategy - Class in org.apache.tephra
Does no retries
NUM_ENTRIES_APPENDED - Static variable in class org.apache.tephra.TxConstants.TransactionLog
Key used to denote the number of entries appended.

O

obtain() - Method in class org.apache.tephra.distributed.ElasticPool
Get a element from the pool.
obtain(long, TimeUnit) - Method in class org.apache.tephra.distributed.ElasticPool
Get a element from the pool.
of(Collection<TransactionAware>) - Static method in class org.apache.tephra.TransactionAwares
Create composite transaction aware object that delegates transaction logic to given collection of TransactionAwares
of(TransactionType) - Static method in enum org.apache.tephra.TransactionManager.InProgressType
 
OLD_TX_OPERATION_ATTRIBUTE_KEY - Static variable in class org.apache.tephra.TxConstants
Deprecated.
This constant is replaced by TxConstants.TX_OPERATION_ATTRIBUTE_KEY
OLD_TX_ROLLBACK_ATTRIBUTE_KEY - Static variable in class org.apache.tephra.TxConstants
Deprecated.
This constant is replaced by TxConstants.TX_ROLLBACK_ATTRIBUTE_KEY
org.apache.tephra - package org.apache.tephra
This package contains implementations of the transaction system v2.
org.apache.tephra.coprocessor - package org.apache.tephra.coprocessor
This package contains HBase coprocessor implementations for the transaction system.
org.apache.tephra.distributed - package org.apache.tephra.distributed
This package contains standalone server of the transaction system v2.
org.apache.tephra.distributed.thrift - package org.apache.tephra.distributed.thrift
 
org.apache.tephra.examples - package org.apache.tephra.examples
This package contains example applications for Tephra designed to illustrate sample Tephra usage and provide out-of-the-box sample applications which can be run to test cluster functionality.
org.apache.tephra.hbase - package org.apache.tephra.hbase
 
org.apache.tephra.hbase.coprocessor - package org.apache.tephra.hbase.coprocessor
 
org.apache.tephra.hbase.txprune - package org.apache.tephra.hbase.txprune
 
org.apache.tephra.inmemory - package org.apache.tephra.inmemory
This package contains in memory implementation of the transaction system v2.
org.apache.tephra.manager - package org.apache.tephra.manager
 
org.apache.tephra.metrics - package org.apache.tephra.metrics
 
org.apache.tephra.persist - package org.apache.tephra.persist
This package contains interfaces and implementations for persisting transaction state.
org.apache.tephra.rpc - package org.apache.tephra.rpc
This package contains class for writing RPC server and client in simple manner.
org.apache.tephra.runtime - package org.apache.tephra.runtime
 
org.apache.tephra.snapshot - package org.apache.tephra.snapshot
This package contains interfaces and implementations for encoding and decoding transaction snapshots.
org.apache.tephra.txprune - package org.apache.tephra.txprune
 
org.apache.tephra.util - package org.apache.tephra.util
 
org.apache.tephra.visibility - package org.apache.tephra.visibility
 
org.apache.tephra.zookeeper - package org.apache.tephra.zookeeper
 
org.apache.thrift.server - package org.apache.thrift.server
 
originalExceptionClass - Variable in exception org.apache.tephra.distributed.thrift.TGenericException
 

P

persist() - Method in class org.apache.tephra.hbase.txprune.CompactionState
persistPruneEntry(byte[], long) - Method in class org.apache.tephra.hbase.txprune.PruneUpperBoundWriter
 
persistRegionEmpty(long) - Method in class org.apache.tephra.hbase.txprune.CompactionState
Persist that the given region is empty at the given time
persistRegionEmpty(byte[], long) - Method in class org.apache.tephra.hbase.txprune.PruneUpperBoundWriter
 
pick() - Method in interface org.apache.tephra.distributed.AbstractClientProvider.EndpointStrategy
Picks a Discoverable using its strategy.
pick() - Method in class org.apache.tephra.distributed.AbstractClientProvider.RandomEndpointStrategy
 
pick() - Method in class org.apache.tephra.distributed.AbstractClientProvider.TimeLimitEndpointStrategy
 
PLUGIN_CLASS_SUFFIX - Static variable in class org.apache.tephra.TxConstants.TransactionPruning
Class name for the plugins will be plugin-name + ".class" suffix
PLUGINS - Static variable in class org.apache.tephra.TxConstants.TransactionPruning
Comma separated list of invalid transaction pruning plugins to load
PooledClientProvider - Class in org.apache.tephra.distributed
This is an tx client provider that uses a bounded size pool of connections.
PooledClientProvider(Configuration, DiscoveryServiceClient) - Constructor for class org.apache.tephra.distributed.PooledClientProvider
 
port - Variable in class org.apache.tephra.inmemory.InMemoryTransactionService
 
postCompact(ObserverContext<RegionCoprocessorEnvironment>, Store, StoreFile, CompactionRequest) - Method in class org.apache.tephra.hbase.coprocessor.TransactionProcessor
 
postFlush(ObserverContext<RegionCoprocessorEnvironment>) - Method in class org.apache.tephra.hbase.coprocessor.TransactionProcessor
 
postTxCommit() - Method in class org.apache.tephra.AbstractTransactionAwareTable
 
postTxCommit() - Method in interface org.apache.tephra.TransactionAware
Called after transaction has been committed.
preCompactScannerOpen(ObserverContext<RegionCoprocessorEnvironment>, Store, List<? extends KeyValueScanner>, ScanType, long, InternalScanner, CompactionRequest) - Method in class org.apache.tephra.hbase.coprocessor.TransactionProcessor
 
preDelete(ObserverContext<RegionCoprocessorEnvironment>, Delete, WALEdit, Durability) - Method in class org.apache.tephra.hbase.coprocessor.TransactionProcessor
 
preFlushScannerOpen(ObserverContext<RegionCoprocessorEnvironment>, Store, KeyValueScanner, InternalScanner) - Method in class org.apache.tephra.hbase.coprocessor.TransactionProcessor
 
preGetOp(ObserverContext<RegionCoprocessorEnvironment>, Get, List<Cell>) - Method in class org.apache.tephra.hbase.coprocessor.TransactionProcessor
 
prepareWait(byte[], TransactionSystemClient) - Static method in class org.apache.tephra.visibility.VisibilityFence
Used by a writer to wait on a fence so that changes are visible to all readers with in-progress transactions.
prePut(ObserverContext<RegionCoprocessorEnvironment>, Put, WALEdit, Durability) - Method in class org.apache.tephra.hbase.coprocessor.TransactionProcessor
 
preScannerOpen(ObserverContext<RegionCoprocessorEnvironment>, Scan, RegionScanner) - Method in class org.apache.tephra.hbase.coprocessor.TransactionProcessor
 
process(WatchedEvent) - Method in class org.apache.tephra.zookeeper.TephraZKClientService
 
PROPERTY_TTL - Static variable in class org.apache.tephra.TxConstants
Property set for org.apache.hadoop.hbase.HColumnDescriptor to configure time-to-live on data within the column family.
PRUNE_ENABLE - Static variable in class org.apache.tephra.TxConstants.TransactionPruning
Flag to enable automatic invalid transaction pruning.
PRUNE_FLUSH_INTERVAL - Static variable in class org.apache.tephra.TxConstants.TransactionPruning
Interval in seconds to schedule flush of prune table entries to store.
PRUNE_GRACE_PERIOD - Static variable in class org.apache.tephra.TxConstants.TransactionPruning
The time in seconds used to pad transaction max lifetime while pruning.
PRUNE_INTERVAL - Static variable in class org.apache.tephra.TxConstants.TransactionPruning
Interval in seconds to schedule prune run.
PRUNE_STATE_TABLE - Static variable in class org.apache.tephra.TxConstants.TransactionPruning
The table used to store intermediate state when pruning is enabled.
PRUNE_UPPER_BOUND_COL - Static variable in class org.apache.tephra.hbase.txprune.DataJanitorState
 
pruneComplete(long, long) - Method in class org.apache.tephra.hbase.txprune.HBaseTransactionPruningPlugin
After invalid list has been pruned, this cleans up state information that is no longer required.
pruneComplete(long, long) - Method in interface org.apache.tephra.txprune.TransactionPruningPlugin
Called after successfully pruning the invalid list using the prune upper bound returned by TransactionPruningPlugin.fetchPruneUpperBound(long, long).
pruneEnable - Variable in class org.apache.tephra.hbase.coprocessor.TransactionProcessor
 
PruneUpperBoundWriter - Class in org.apache.tephra.hbase.txprune
Thread that will write the the prune upper bound.
PruneUpperBoundWriter(TableName, DataJanitorState, long) - Constructor for class org.apache.tephra.hbase.txprune.PruneUpperBoundWriter
 
PruneUpperBoundWriterSupplier - Class in org.apache.tephra.hbase.txprune
Supplies instances of PruneUpperBoundWriter implementations.
PruneUpperBoundWriterSupplier(TableName, DataJanitorState, long) - Constructor for class org.apache.tephra.hbase.txprune.PruneUpperBoundWriterSupplier
 
put(Put) - Method in class org.apache.tephra.hbase.SecondaryIndexTable
 
put(List<Put>) - Method in class org.apache.tephra.hbase.SecondaryIndexTable
 
put(Put) - Method in class org.apache.tephra.hbase.TransactionAwareHTable
 
put(List<Put>) - Method in class org.apache.tephra.hbase.TransactionAwareHTable
 

R

rate(String) - Method in class org.apache.tephra.metrics.DefaultMetricsCollector
 
rate(String, int) - Method in class org.apache.tephra.metrics.DefaultMetricsCollector
 
rate(String) - Method in interface org.apache.tephra.metrics.MetricsCollector
Report a metric as a count over a given time duration.
rate(String, int) - Method in interface org.apache.tephra.metrics.MetricsCollector
Report a metric as a count over a given time duration.
rate(String) - Method in class org.apache.tephra.metrics.TxMetricsCollector
 
rate(String, int) - Method in class org.apache.tephra.metrics.TxMetricsCollector
 
read(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TBoolean
 
read(TProtocol) - Method in exception org.apache.tephra.distributed.thrift.TGenericException
 
read(TProtocol) - Method in exception org.apache.tephra.distributed.thrift.TInvalidTruncateTimeException
 
read(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransaction
 
read(TProtocol) - Method in exception org.apache.tephra.distributed.thrift.TTransactionCouldNotTakeSnapshotException
 
read(TProtocol) - Method in exception org.apache.tephra.distributed.thrift.TTransactionNotInProgressException
 
read(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.abortTx_args
 
read(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.abortTx_result
 
read(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_args
 
read(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_result
 
read(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_args
 
read(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_result
 
read(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_args
 
read(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_result
 
read(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.getSnapshot_args
 
read(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.getSnapshot_result
 
read(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidateTx_args
 
read(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidateTx_result
 
read(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidTxSize_args
 
read(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidTxSize_result
 
read(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.resetState_args
 
read(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.resetState_result
 
read(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startLong_args
 
read(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startLong_result
 
read(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShort_args
 
read(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShort_result
 
read(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortTimeout_args
 
read(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortTimeout_result
 
read(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_args
 
read(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_result
 
read(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.status_args
 
read(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.status_result
 
read(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTx_args
 
read(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTx_result
 
read(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_args
 
read(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_result
 
READ_NON_TX_DATA - Static variable in class org.apache.tephra.TxConstants
Indicates whether data written before Tephra was enabled on a table should be readable.
readBytes() - Method in class org.apache.tephra.snapshot.BinaryDecoder
Read a byte sequence.
readFields(DataInput) - Method in class co.cask.tephra.persist.TransactionEdit
Deprecated.
 
readFields(DataInput) - Method in class org.apache.tephra.persist.AbstractTransactionLog.Entry
 
readFields(DataInput) - Method in class org.apache.tephra.persist.TransactionEdit
 
readInt() - Method in class org.apache.tephra.snapshot.BinaryDecoder
Read one int from the input.
readLong() - Method in class org.apache.tephra.snapshot.BinaryDecoder
Read one long int from the input.
readMarker(SequenceFile.Reader) - Method in class org.apache.tephra.persist.CommitMarkerCodec
 
readNonTxnData - Variable in class org.apache.tephra.hbase.coprocessor.TransactionProcessor
 
readPointer - Variable in class org.apache.tephra.distributed.thrift.TTransaction
 
record(CompactionRequest, TransactionVisibilityState) - Method in class org.apache.tephra.hbase.txprune.CompactionState
Records the transaction state used for a compaction.
recoverFileLease(FileSystem, Path, Configuration) - Method in class org.apache.tephra.persist.HDFSUtil
Recover the lease from HDFS, retrying multiple times.
recoverState() - Method in class org.apache.tephra.TransactionManager
 
recv_abortTx() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Client
 
recv_canCommitTx() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Client
 
recv_checkpoint() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Client
 
recv_commitTx() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Client
 
recv_getSnapshot() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Client
 
recv_invalidateTx() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Client
 
recv_invalidTxSize() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Client
 
recv_resetState() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Client
 
recv_startLong() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Client
 
recv_startShort() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Client
 
recv_startShortTimeout() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Client
 
recv_startShortWithTimeout() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Client
 
recv_status() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Client
 
recv_truncateInvalidTx() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Client
 
recv_truncateInvalidTxBefore() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Client
 
recycle(T) - Method in class org.apache.tephra.distributed.ElasticPool
A method to recycle an existing element when it is returned to the pool.
RegionPruneInfo - Class in org.apache.tephra.txprune
Contains the region id, prune upper bound and prune record timestamp information.
RegionPruneInfo(byte[], String, long, long) - Constructor for class org.apache.tephra.txprune.RegionPruneInfo
 
release(T) - Method in class org.apache.tephra.distributed.ElasticPool
Returns an element to the pool of available elements.
release() - Method in class org.apache.tephra.hbase.txprune.PruneUpperBoundWriterSupplier
 
remove(long) - Method in class org.apache.tephra.manager.InvalidTxList
 
removeAll(Collection<? extends Long>) - Method in class org.apache.tephra.manager.InvalidTxList
 
removeAll(LongList) - Method in class org.apache.tephra.manager.InvalidTxList
 
removeTransactionAware(TransactionAware) - Method in class org.apache.tephra.TransactionContext
Removes a TransactionAware and withdraws from participation in the transaction.
REPORT_PERIOD_DEFAULT - Static variable in class org.apache.tephra.TxConstants.Metrics
Default report period for metrics, in seconds.
REPORT_PERIOD_KEY - Static variable in class org.apache.tephra.TxConstants.Metrics
Frequency at which metrics should be reported, in seconds.
requestInvoke(AbstractNonblockingServer.FrameBuffer) - Method in class org.apache.thrift.server.TThreadedSelectorServerWithFix
We override the standard invoke method here to queue the invocation for invoker service instead of immediately invoking.
reset() - Method in class org.apache.tephra.hbase.coprocessor.CellSkipFilter
 
reset() - Method in class org.apache.tephra.hbase.coprocessor.TransactionVisibilityFilter
 
resetPruneState() - Method in class org.apache.tephra.hbase.coprocessor.TransactionProcessor
Stop and clear state related to pruning.
resetState(AsyncMethodCallback<TTransactionServer.AsyncClient.resetState_call>) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.AsyncClient
 
resetState(AsyncMethodCallback<TTransactionServer.AsyncClient.resetState_call>) - Method in interface org.apache.tephra.distributed.thrift.TTransactionServer.AsyncIface
 
resetState() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Client
 
resetState() - Method in interface org.apache.tephra.distributed.thrift.TTransactionServer.Iface
 
resetState() - Method in class org.apache.tephra.distributed.TransactionServiceClient
 
resetState() - Method in class org.apache.tephra.distributed.TransactionServiceThriftClient
 
resetState() - Method in class org.apache.tephra.distributed.TransactionServiceThriftHandler
 
resetState() - Method in class org.apache.tephra.inmemory.DetachedTxSystemClient
 
resetState() - Method in class org.apache.tephra.inmemory.InMemoryTxSystemClient
 
resetState() - Method in class org.apache.tephra.inmemory.MinimalTxSystemClient
 
resetState() - Method in class org.apache.tephra.TransactionManager
Resets the state of the transaction manager.
resetState() - Method in interface org.apache.tephra.TransactionSystemClient
Resets the state of the transaction manager.
RetryNTimes - Class in org.apache.tephra.distributed
A retry strategy that makes N attempts and then gives up.
RetryNTimes.Provider - Class in org.apache.tephra.distributed
A retry strategy provider for this strategy.
RetryNTimes.Provider() - Constructor for class org.apache.tephra.distributed.RetryNTimes.Provider
 
retryOnConflict(int, long) - Static method in class org.apache.tephra.RetryStrategies
 
RetryOnConflictStrategy - Class in org.apache.tephra
Retries transaction execution when transaction fails with TransactionConflictException.
RetryOnConflictStrategy(int, long) - Constructor for class org.apache.tephra.RetryOnConflictStrategy
 
RetryStrategies - Class in org.apache.tephra
Collection of RetryStrategys.
RetryStrategy - Class in org.apache.tephra.distributed
A retry strategy is an abstraction over how the remote tx client shuold retry operations after connection failures.
RetryStrategy() - Constructor for class org.apache.tephra.distributed.RetryStrategy
 
RetryStrategy - Interface in org.apache.tephra
Retry strategy for failed transactions
RetryStrategyProvider - Interface in org.apache.tephra.distributed
A retry strategy provider is used by the tx client to get a new retry strategy for every call.
RetryWithBackoff - Class in org.apache.tephra.distributed
A retry strategy that makes N attempts and then gives up.
RetryWithBackoff.Provider - Class in org.apache.tephra.distributed
A provider for this retry strategy.
RetryWithBackoff.Provider() - Constructor for class org.apache.tephra.distributed.RetryWithBackoff.Provider
 
returnClient(TransactionServiceThriftClient) - Method in class org.apache.tephra.distributed.PooledClientProvider
 
returnClient(TransactionServiceThriftClient) - Method in class org.apache.tephra.distributed.SingleUseClientProvider
 
returnClient(TransactionServiceThriftClient) - Method in class org.apache.tephra.distributed.ThreadLocalClientProvider
 
returnClient(TransactionServiceThriftClient) - Method in interface org.apache.tephra.distributed.ThriftClientProvider
Release an tx client back to the provider's pool, if the client is valid.
rollbackTx() - Method in class org.apache.tephra.AbstractTransactionAwareTable
 
rollbackTx() - Method in interface org.apache.tephra.TransactionAware
Called during transaction rollback (for whatever reason: conflicts, errors, etc.).
RPCServiceHandler - Interface in org.apache.tephra.rpc
Defines lifecycle interface for all rpc handlers.
run() - Method in class org.apache.tephra.examples.BalanceBooks
Runs all clients and waits for them to complete.
run() - Method in class org.apache.tephra.rpc.ThriftRPCServer
 
run() - Method in class org.apache.tephra.txprune.TransactionPruningRunnable
 
run() - Method in class org.apache.thrift.server.TThreadedSelectorServerWithFix.AcceptThread
The work loop.
run() - Method in class org.apache.thrift.server.TThreadedSelectorServerWithFix.SelectorThread
The work loop.

S

saveEmptyRegionForTime(long, byte[]) - Method in class org.apache.tephra.hbase.txprune.DataJanitorState
Save the given region as empty as of the given time.
saveInactiveTransactionBoundForTime(long, long) - Method in class org.apache.tephra.hbase.txprune.DataJanitorState
Persist inactive transaction bound for a given time.
savePruneUpperBoundForRegion(byte[], long) - Method in class org.apache.tephra.hbase.txprune.DataJanitorState
Persist the latest prune upper bound for a given region.
saveRegionsForTime(long, Set<byte[]>) - Method in class org.apache.tephra.hbase.txprune.DataJanitorState
Persist the regions for the given time.
SecondaryIndexTable - Class in org.apache.tephra.hbase
A Transactional SecondaryIndexTable.
SecondaryIndexTable(TransactionServiceClient, HTableInterface, byte[]) - Constructor for class org.apache.tephra.hbase.SecondaryIndexTable
 
selectorThreads - Variable in class org.apache.thrift.server.TThreadedSelectorServerWithFix.Args
The number of threads for selecting on already-accepted connections
selectorThreads(int) - Method in class org.apache.thrift.server.TThreadedSelectorServerWithFix.Args
 
send_abortTx(TTransaction) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Client
 
send_canCommitTx(TTransaction, Set<ByteBuffer>) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Client
 
send_checkpoint(TTransaction) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Client
 
send_commitTx(TTransaction) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Client
 
send_getSnapshot() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Client
 
send_invalidateTx(long) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Client
 
send_invalidTxSize() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Client
 
send_resetState() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Client
 
send_startLong() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Client
 
send_startShort() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Client
 
send_startShortTimeout(int) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Client
 
send_startShortWithTimeout(int) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Client
 
send_status() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Client
 
send_truncateInvalidTx(Set<Long>) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Client
 
send_truncateInvalidTxBefore(long) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Client
 
setACL(String, Iterable<ACL>) - Method in class org.apache.tephra.zookeeper.TephraZKClientService
 
setACL(String, Iterable<ACL>, int) - Method in class org.apache.tephra.zookeeper.TephraZKClientService
 
setAllowNonTransactional(boolean) - Method in class org.apache.tephra.AbstractTransactionAwareTable
Set whether the instance allows non-transactional operations.
setAutoFlush(boolean) - Method in class org.apache.tephra.hbase.TransactionAwareHTable
 
setAutoFlush(boolean, boolean) - Method in class org.apache.tephra.hbase.TransactionAwareHTable
 
setAutoFlushTo(boolean) - Method in class org.apache.tephra.hbase.TransactionAwareHTable
 
setChanges(Set<ByteBuffer>) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_args
 
setChangesIsSet(boolean) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_args
 
setCheckpointWritePointers(List<Long>) - Method in class org.apache.tephra.distributed.thrift.TTransaction
 
setCheckpointWritePointersIsSet(boolean) - Method in class org.apache.tephra.distributed.thrift.TTransaction
 
setConf(Configuration) - Method in class org.apache.tephra.coprocessor.TransactionStateCache
 
setData(String, byte[]) - Method in class org.apache.tephra.zookeeper.TephraZKClientService
 
setData(String, byte[], int) - Method in class org.apache.tephra.zookeeper.TephraZKClientService
 
setE(TTransactionNotInProgressException) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_result
 
setE(TTransactionNotInProgressException) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_result
 
setE(TTransactionNotInProgressException) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_result
 
setE(TTransactionCouldNotTakeSnapshotException) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.getSnapshot_result
 
setE(TGenericException) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_result
 
setE(TInvalidTruncateTimeException) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_result
 
setEIsSet(boolean) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_result
 
setEIsSet(boolean) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_result
 
setEIsSet(boolean) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_result
 
setEIsSet(boolean) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.getSnapshot_result
 
setEIsSet(boolean) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_result
 
setEIsSet(boolean) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_result
 
setFieldValue(TBoolean._Fields, Object) - Method in class org.apache.tephra.distributed.thrift.TBoolean
 
setFieldValue(TGenericException._Fields, Object) - Method in exception org.apache.tephra.distributed.thrift.TGenericException
 
setFieldValue(TInvalidTruncateTimeException._Fields, Object) - Method in exception org.apache.tephra.distributed.thrift.TInvalidTruncateTimeException
 
setFieldValue(TTransaction._Fields, Object) - Method in class org.apache.tephra.distributed.thrift.TTransaction
 
setFieldValue(TTransactionCouldNotTakeSnapshotException._Fields, Object) - Method in exception org.apache.tephra.distributed.thrift.TTransactionCouldNotTakeSnapshotException
 
setFieldValue(TTransactionNotInProgressException._Fields, Object) - Method in exception org.apache.tephra.distributed.thrift.TTransactionNotInProgressException
 
setFieldValue(TTransactionServer.abortTx_args._Fields, Object) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.abortTx_args
 
setFieldValue(TTransactionServer.abortTx_result._Fields, Object) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.abortTx_result
 
setFieldValue(TTransactionServer.canCommitTx_args._Fields, Object) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_args
 
setFieldValue(TTransactionServer.canCommitTx_result._Fields, Object) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_result
 
setFieldValue(TTransactionServer.checkpoint_args._Fields, Object) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_args
 
setFieldValue(TTransactionServer.checkpoint_result._Fields, Object) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_result
 
setFieldValue(TTransactionServer.commitTx_args._Fields, Object) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_args
 
setFieldValue(TTransactionServer.commitTx_result._Fields, Object) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_result
 
setFieldValue(TTransactionServer.getSnapshot_args._Fields, Object) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.getSnapshot_args
 
setFieldValue(TTransactionServer.getSnapshot_result._Fields, Object) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.getSnapshot_result
 
setFieldValue(TTransactionServer.invalidateTx_args._Fields, Object) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidateTx_args
 
setFieldValue(TTransactionServer.invalidateTx_result._Fields, Object) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidateTx_result
 
setFieldValue(TTransactionServer.invalidTxSize_args._Fields, Object) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidTxSize_args
 
setFieldValue(TTransactionServer.invalidTxSize_result._Fields, Object) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidTxSize_result
 
setFieldValue(TTransactionServer.resetState_args._Fields, Object) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.resetState_args
 
setFieldValue(TTransactionServer.resetState_result._Fields, Object) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.resetState_result
 
setFieldValue(TTransactionServer.startLong_args._Fields, Object) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startLong_args
 
setFieldValue(TTransactionServer.startLong_result._Fields, Object) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startLong_result
 
setFieldValue(TTransactionServer.startShort_args._Fields, Object) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShort_args
 
setFieldValue(TTransactionServer.startShort_result._Fields, Object) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShort_result
 
setFieldValue(TTransactionServer.startShortTimeout_args._Fields, Object) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortTimeout_args
 
setFieldValue(TTransactionServer.startShortTimeout_result._Fields, Object) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortTimeout_result
 
setFieldValue(TTransactionServer.startShortWithTimeout_args._Fields, Object) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_args
 
setFieldValue(TTransactionServer.startShortWithTimeout_result._Fields, Object) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_result
 
setFieldValue(TTransactionServer.status_args._Fields, Object) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.status_args
 
setFieldValue(TTransactionServer.status_result._Fields, Object) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.status_result
 
setFieldValue(TTransactionServer.truncateInvalidTx_args._Fields, Object) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTx_args
 
setFieldValue(TTransactionServer.truncateInvalidTx_result._Fields, Object) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTx_result
 
setFieldValue(TTransactionServer.truncateInvalidTxBefore_args._Fields, Object) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_args
 
setFieldValue(TTransactionServer.truncateInvalidTxBefore_result._Fields, Object) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_result
 
setFirstShort(long) - Method in class org.apache.tephra.distributed.thrift.TTransaction
 
setFirstShortIsSet(boolean) - Method in class org.apache.tephra.distributed.thrift.TTransaction
 
setHost(String) - Method in class org.apache.tephra.rpc.ThriftRPCServer.Builder
 
setInProgress(List<Long>) - Method in class org.apache.tephra.distributed.thrift.TTransaction
 
setInProgressIsSet(boolean) - Method in class org.apache.tephra.distributed.thrift.TTransaction
 
setInvalids(List<Long>) - Method in class org.apache.tephra.distributed.thrift.TTransaction
 
setInvalidsIsSet(boolean) - Method in class org.apache.tephra.distributed.thrift.TTransaction
 
setIOThreads(int) - Method in class org.apache.tephra.rpc.ThriftRPCServer.Builder
 
setMaxReadBufferBytes(int) - Method in class org.apache.tephra.rpc.ThriftRPCServer.Builder
 
setMessage(String) - Method in exception org.apache.tephra.distributed.thrift.TGenericException
 
setMessage(String) - Method in exception org.apache.tephra.distributed.thrift.TInvalidTruncateTimeException
 
setMessage(String) - Method in exception org.apache.tephra.distributed.thrift.TTransactionCouldNotTakeSnapshotException
 
setMessage(String) - Method in exception org.apache.tephra.distributed.thrift.TTransactionNotInProgressException
 
setMessageIsSet(boolean) - Method in exception org.apache.tephra.distributed.thrift.TGenericException
 
setMessageIsSet(boolean) - Method in exception org.apache.tephra.distributed.thrift.TInvalidTruncateTimeException
 
setMessageIsSet(boolean) - Method in exception org.apache.tephra.distributed.thrift.TTransactionCouldNotTakeSnapshotException
 
setMessageIsSet(boolean) - Method in exception org.apache.tephra.distributed.thrift.TTransactionNotInProgressException
 
setName(String) - Method in class org.apache.tephra.rpc.ThriftRPCServer.Builder
 
setOriginalExceptionClass(String) - Method in exception org.apache.tephra.distributed.thrift.TGenericException
 
setOriginalExceptionClassIsSet(boolean) - Method in exception org.apache.tephra.distributed.thrift.TGenericException
 
setPort(int) - Method in class org.apache.tephra.rpc.ThriftRPCServer.Builder
 
setReadPointer(long) - Method in class org.apache.tephra.distributed.thrift.TTransaction
 
setReadPointerIsSet(boolean) - Method in class org.apache.tephra.distributed.thrift.TTransaction
 
setSuccess(TBoolean) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_result
 
setSuccess(TTransaction) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_result
 
setSuccess(TBoolean) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_result
 
setSuccess(byte[]) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.getSnapshot_result
 
setSuccess(ByteBuffer) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.getSnapshot_result
 
setSuccess(boolean) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidateTx_result
 
setSuccess(int) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidTxSize_result
 
setSuccess(TTransaction) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startLong_result
 
setSuccess(TTransaction) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShort_result
 
setSuccess(TTransaction) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortTimeout_result
 
setSuccess(TTransaction) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_result
 
setSuccess(String) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.status_result
 
setSuccess(TBoolean) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTx_result
 
setSuccess(TBoolean) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_result
 
setSuccessIsSet(boolean) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_result
 
setSuccessIsSet(boolean) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_result
 
setSuccessIsSet(boolean) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_result
 
setSuccessIsSet(boolean) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.getSnapshot_result
 
setSuccessIsSet(boolean) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidateTx_result
 
setSuccessIsSet(boolean) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidTxSize_result
 
setSuccessIsSet(boolean) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startLong_result
 
setSuccessIsSet(boolean) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShort_result
 
setSuccessIsSet(boolean) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortTimeout_result
 
setSuccessIsSet(boolean) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_result
 
setSuccessIsSet(boolean) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.status_result
 
setSuccessIsSet(boolean) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTx_result
 
setSuccessIsSet(boolean) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_result
 
setTime(long) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_args
 
setTimeIsSet(boolean) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_args
 
setTimeout(int) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortTimeout_args
 
setTimeout(int) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_args
 
setTimeoutIsSet(boolean) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortTimeout_args
 
setTimeoutIsSet(boolean) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_args
 
setTransactionId(long) - Method in class org.apache.tephra.distributed.thrift.TTransaction
 
setTransactionIdIsSet(boolean) - Method in class org.apache.tephra.distributed.thrift.TTransaction
 
setTx(TTransaction) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.abortTx_args
 
setTx(TTransaction) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_args
 
setTx(TTransaction) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_args
 
setTx(TTransaction) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_args
 
setTx(long) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidateTx_args
 
setTxIsSet(boolean) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.abortTx_args
 
setTxIsSet(boolean) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_args
 
setTxIsSet(boolean) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_args
 
setTxIsSet(boolean) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_args
 
setTxIsSet(boolean) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidateTx_args
 
setTxns(Set<Long>) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTx_args
 
setTxnsIsSet(boolean) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTx_args
 
setType(TTransactionType) - Method in class org.apache.tephra.distributed.thrift.TTransaction
 
setTypeIsSet(boolean) - Method in class org.apache.tephra.distributed.thrift.TTransaction
 
setupStorage() - Method in class org.apache.tephra.persist.HDFSTransactionStateStorage
 
setupStorage() - Method in class org.apache.tephra.persist.LocalFileTransactionStateStorage
 
setupStorage() - Method in class org.apache.tephra.persist.NoOpTransactionStateStorage
 
setupStorage() - Method in interface org.apache.tephra.persist.TransactionStateStorage
Create the directories required for the transaction state stage.
setValue(boolean) - Method in class org.apache.tephra.distributed.thrift.TBoolean
 
setValueIsSet(boolean) - Method in class org.apache.tephra.distributed.thrift.TBoolean
 
setVisibility(Transaction.VisibilityLevel) - Method in class org.apache.tephra.Transaction
Sets the visibility level for read operations.
setVisibilityLevel(TVisibilityLevel) - Method in class org.apache.tephra.distributed.thrift.TTransaction
 
setVisibilityLevelIsSet(boolean) - Method in class org.apache.tephra.distributed.thrift.TTransaction
 
setWorkerThreads(int) - Method in class org.apache.tephra.rpc.ThriftRPCServer.Builder
 
setWriteBufferSize(long) - Method in class org.apache.tephra.hbase.TransactionAwareHTable
 
setWritePointer(long) - Method in class org.apache.tephra.distributed.thrift.TTransaction
 
setWritePointerIsSet(boolean) - Method in class org.apache.tephra.distributed.thrift.TTransaction
 
shutDown() - Method in class org.apache.tephra.coprocessor.TransactionStateCache
 
shutDown() - Method in class org.apache.tephra.hbase.txprune.PruneUpperBoundWriter
 
shutDown() - Method in class org.apache.tephra.metrics.DefaultMetricsCollector
 
shutDown() - Method in class org.apache.tephra.metrics.TxMetricsCollector
 
shutDown() - Method in class org.apache.tephra.persist.HDFSTransactionStateStorage
 
shutDown() - Method in class org.apache.tephra.persist.LocalFileTransactionStateStorage
 
shutDown() - Method in class org.apache.tephra.persist.NoOpTransactionStateStorage
 
shutDown() - Method in class org.apache.tephra.rpc.ThriftRPCServer
 
shutDown() - Method in class org.apache.tephra.txprune.TransactionPruningService
 
SingleUseClientProvider - Class in org.apache.tephra.distributed
An tx client provider that creates a new connection every time.
SingleUseClientProvider(Configuration, DiscoveryServiceClient, int) - Constructor for class org.apache.tephra.distributed.SingleUseClientProvider
 
size() - Method in class org.apache.tephra.manager.InvalidTxList
 
SnapshotCodec - Interface in org.apache.tephra.snapshot
Interface to decode and encode a transaction snapshot.
SnapshotCodecProvider - Class in org.apache.tephra.snapshot
Maintains the codecs for all known versions of the transaction snapshot encoding.
SnapshotCodecProvider(Configuration) - Constructor for class org.apache.tephra.snapshot.SnapshotCodecProvider
 
SnapshotCodecV2 - Class in org.apache.tephra.snapshot
Handles serialization/deserialization of a TransactionSnapshot and its elements to byte[].
SnapshotCodecV2() - Constructor for class org.apache.tephra.snapshot.SnapshotCodecV2
 
SnapshotCodecV3 - Class in org.apache.tephra.snapshot
Handles serialization/deserialization of a TransactionSnapshot and its elements to byte[].
SnapshotCodecV3() - Constructor for class org.apache.tephra.snapshot.SnapshotCodecV3
 
SnapshotCodecV4 - Class in org.apache.tephra.snapshot
Handles serialization/deserialization of a TransactionSnapshot and its elements to byte[].
SnapshotCodecV4() - Constructor for class org.apache.tephra.snapshot.SnapshotCodecV4
 
start(CoprocessorEnvironment) - Method in class org.apache.tephra.hbase.coprocessor.TransactionProcessor
 
start() - Method in class org.apache.tephra.TransactionContext
Starts a new transaction.
start(int) - Method in class org.apache.tephra.TransactionContext
Starts a new transaction.
start() - Method in class org.apache.tephra.TransactionServiceMain
Invoked by jsvc to start the program.
startLong(AsyncMethodCallback<TTransactionServer.AsyncClient.startLong_call>) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.AsyncClient
 
startLong(AsyncMethodCallback<TTransactionServer.AsyncClient.startLong_call>) - Method in interface org.apache.tephra.distributed.thrift.TTransactionServer.AsyncIface
 
startLong() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Client
 
startLong() - Method in interface org.apache.tephra.distributed.thrift.TTransactionServer.Iface
 
startLong() - Method in class org.apache.tephra.distributed.TransactionServiceClient
 
startLong() - Method in class org.apache.tephra.distributed.TransactionServiceThriftClient
 
startLong() - Method in class org.apache.tephra.distributed.TransactionServiceThriftHandler
 
startLong() - Method in class org.apache.tephra.inmemory.DetachedTxSystemClient
 
startLong() - Method in class org.apache.tephra.inmemory.InMemoryTxSystemClient
 
startLong() - Method in class org.apache.tephra.inmemory.MinimalTxSystemClient
 
startLong() - Method in class org.apache.tephra.TransactionManager
Start a long transaction.
startLong() - Method in interface org.apache.tephra.TransactionSystemClient
Starts new long transaction.
startShort(AsyncMethodCallback<TTransactionServer.AsyncClient.startShort_call>) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.AsyncClient
 
startShort(AsyncMethodCallback<TTransactionServer.AsyncClient.startShort_call>) - Method in interface org.apache.tephra.distributed.thrift.TTransactionServer.AsyncIface
 
startShort() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Client
 
startShort() - Method in interface org.apache.tephra.distributed.thrift.TTransactionServer.Iface
 
startShort() - Method in class org.apache.tephra.distributed.TransactionServiceClient
 
startShort(int) - Method in class org.apache.tephra.distributed.TransactionServiceClient
 
startShort() - Method in class org.apache.tephra.distributed.TransactionServiceThriftClient
 
startShort(int) - Method in class org.apache.tephra.distributed.TransactionServiceThriftClient
 
startShort() - Method in class org.apache.tephra.distributed.TransactionServiceThriftHandler
 
startShort() - Method in class org.apache.tephra.inmemory.DetachedTxSystemClient
 
startShort(int) - Method in class org.apache.tephra.inmemory.DetachedTxSystemClient
 
startShort() - Method in class org.apache.tephra.inmemory.InMemoryTxSystemClient
 
startShort(int) - Method in class org.apache.tephra.inmemory.InMemoryTxSystemClient
 
startShort() - Method in class org.apache.tephra.inmemory.MinimalTxSystemClient
 
startShort(int) - Method in class org.apache.tephra.inmemory.MinimalTxSystemClient
 
startShort() - Method in class org.apache.tephra.TransactionManager
Start a short transaction with the default timeout.
startShort(int) - Method in class org.apache.tephra.TransactionManager
Start a short transaction with a given timeout.
startShort() - Method in interface org.apache.tephra.TransactionSystemClient
Starts new short transaction.
startShort(int) - Method in interface org.apache.tephra.TransactionSystemClient
Starts new short transaction.
startShortTimeout(int, AsyncMethodCallback<TTransactionServer.AsyncClient.startShortTimeout_call>) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.AsyncClient
 
startShortTimeout(int, AsyncMethodCallback<TTransactionServer.AsyncClient.startShortTimeout_call>) - Method in interface org.apache.tephra.distributed.thrift.TTransactionServer.AsyncIface
 
startShortTimeout(int) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Client
 
startShortTimeout(int) - Method in interface org.apache.tephra.distributed.thrift.TTransactionServer.Iface
 
startShortTimeout(int) - Method in class org.apache.tephra.distributed.TransactionServiceThriftHandler
 
startShortWithTimeout(int, AsyncMethodCallback<TTransactionServer.AsyncClient.startShortWithTimeout_call>) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.AsyncClient
 
startShortWithTimeout(int, AsyncMethodCallback<TTransactionServer.AsyncClient.startShortWithTimeout_call>) - Method in interface org.apache.tephra.distributed.thrift.TTransactionServer.AsyncIface
 
startShortWithTimeout(int) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Client
 
startShortWithTimeout(int) - Method in interface org.apache.tephra.distributed.thrift.TTransactionServer.Iface
 
startShortWithTimeout(int) - Method in class org.apache.tephra.distributed.TransactionServiceThriftHandler
 
startThreads() - Method in class org.apache.thrift.server.TThreadedSelectorServerWithFix
Start the accept and selector threads running to deal with clients.
startTx(Transaction) - Method in class org.apache.tephra.AbstractTransactionAwareTable
 
startTx(Transaction) - Method in interface org.apache.tephra.TransactionAware
Called when new transaction has started.
startUp() - Method in class org.apache.tephra.coprocessor.TransactionStateCache
 
startUp() - Method in class org.apache.tephra.hbase.txprune.PruneUpperBoundWriter
 
startUp() - Method in class org.apache.tephra.metrics.DefaultMetricsCollector
 
startUp() - Method in class org.apache.tephra.metrics.TxMetricsCollector
 
startUp() - Method in class org.apache.tephra.persist.HDFSTransactionStateStorage
 
startUp() - Method in class org.apache.tephra.persist.LocalFileTransactionStateStorage
 
startUp() - Method in class org.apache.tephra.persist.NoOpTransactionStateStorage
 
startUp() - Method in class org.apache.tephra.rpc.ThriftRPCServer
 
startUp() - Method in class org.apache.tephra.txprune.TransactionPruningService
 
status(AsyncMethodCallback<TTransactionServer.AsyncClient.status_call>) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.AsyncClient
 
status(AsyncMethodCallback<TTransactionServer.AsyncClient.status_call>) - Method in interface org.apache.tephra.distributed.thrift.TTransactionServer.AsyncIface
 
status() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Client
 
status() - Method in interface org.apache.tephra.distributed.thrift.TTransactionServer.Iface
 
status() - Method in class org.apache.tephra.distributed.TransactionServiceClient
 
status() - Method in class org.apache.tephra.distributed.TransactionServiceThriftClient
 
status() - Method in class org.apache.tephra.distributed.TransactionServiceThriftHandler
 
status() - Method in class org.apache.tephra.inmemory.DetachedTxSystemClient
 
status() - Method in class org.apache.tephra.inmemory.InMemoryTxSystemClient
 
status() - Method in class org.apache.tephra.inmemory.MinimalTxSystemClient
 
status() - Method in interface org.apache.tephra.TransactionSystemClient
Return the status of the transaction Manager
STATUS_NOTOK - Static variable in class org.apache.tephra.TxConstants
 
STATUS_OK - Static variable in class org.apache.tephra.TxConstants
 
stop(CoprocessorEnvironment) - Method in class org.apache.tephra.hbase.coprocessor.TransactionProcessor
 
stop() - Method in class org.apache.tephra.hbase.txprune.CompactionState
Releases the usage PruneUpperBoundWriter.
stop() - Method in class org.apache.tephra.TransactionServiceMain
Invoked by jsvc to stop the program.
stop() - Method in class org.apache.thrift.server.TThreadedSelectorServerWithFix
Stop serving and shut everything down.
stopTimeoutUnit(TimeUnit) - Method in class org.apache.thrift.server.TThreadedSelectorServerWithFix.Args
 
stopTimeoutVal(int) - Method in class org.apache.thrift.server.TThreadedSelectorServerWithFix.Args
 
submit(TransactionExecutor.Function<I, O>, I) - Method in class org.apache.tephra.AbstractTransactionExecutor
 
submit(TransactionExecutor.Procedure<I>, I) - Method in class org.apache.tephra.AbstractTransactionExecutor
 
submit(Callable<O>) - Method in class org.apache.tephra.AbstractTransactionExecutor
 
submit(TransactionExecutor.Subroutine) - Method in class org.apache.tephra.AbstractTransactionExecutor
 
submit(TransactionExecutor.Function<I, O>, I) - Method in interface org.apache.tephra.TransactionExecutor
Same as TransactionExecutor.execute(Function, Object) but executes asynchronously
submit(TransactionExecutor.Procedure<I>, I) - Method in interface org.apache.tephra.TransactionExecutor
Same as TransactionExecutor.execute(Procedure, Object) but executes asynchronously
submit(Callable<O>) - Method in interface org.apache.tephra.TransactionExecutor
Same as TransactionExecutor.execute(Callable) but executes asynchronously
submit(TransactionExecutor.Subroutine) - Method in interface org.apache.tephra.TransactionExecutor
Same as TransactionExecutor.execute(Subroutine) but executes asynchronously
success - Variable in class org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_result
 
success - Variable in class org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_result
 
success - Variable in class org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_result
 
success - Variable in class org.apache.tephra.distributed.thrift.TTransactionServer.getSnapshot_result
 
success - Variable in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidateTx_result
 
success - Variable in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidTxSize_result
 
success - Variable in class org.apache.tephra.distributed.thrift.TTransactionServer.startLong_result
 
success - Variable in class org.apache.tephra.distributed.thrift.TTransactionServer.startShort_result
 
success - Variable in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortTimeout_result
 
success - Variable in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_result
 
success - Variable in class org.apache.tephra.distributed.thrift.TTransactionServer.status_result
 
success - Variable in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTx_result
 
success - Variable in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_result
 
sync() - Method in interface org.apache.tephra.persist.TransactionLogWriter
Syncs any pending transaction edits added through TransactionLogWriter.append(AbstractTransactionLog.Entry), but not yet flushed to durable storage.

T

takeSnapshot(OutputStream) - Method in class org.apache.tephra.TransactionManager
Take a snapshot of the transaction state and serialize it into the given output stream.
TBoolean - Class in org.apache.tephra.distributed.thrift
 
TBoolean() - Constructor for class org.apache.tephra.distributed.thrift.TBoolean
 
TBoolean(boolean) - Constructor for class org.apache.tephra.distributed.thrift.TBoolean
 
TBoolean(TBoolean) - Constructor for class org.apache.tephra.distributed.thrift.TBoolean
Performs a deep copy on other.
TBoolean._Fields - Enum in org.apache.tephra.distributed.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TephraZKClientService - Class in org.apache.tephra.zookeeper
The implementation of ZKClientService.
TephraZKClientService(String, int, Watcher, Multimap<String, byte[]>) - Constructor for class org.apache.tephra.zookeeper.TephraZKClientService
Create a new instance.
TGenericException - Exception in org.apache.tephra.distributed.thrift
 
TGenericException() - Constructor for exception org.apache.tephra.distributed.thrift.TGenericException
 
TGenericException(String, String) - Constructor for exception org.apache.tephra.distributed.thrift.TGenericException
 
TGenericException(TGenericException) - Constructor for exception org.apache.tephra.distributed.thrift.TGenericException
Performs a deep copy on other.
TGenericException._Fields - Enum in org.apache.tephra.distributed.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ThreadLocalClientProvider - Class in org.apache.tephra.distributed
An tx client provider that uses thread local to maintain at most one open connection per thread.
ThreadLocalClientProvider(Configuration, DiscoveryServiceClient) - Constructor for class org.apache.tephra.distributed.ThreadLocalClientProvider
 
threads - Variable in class org.apache.tephra.inmemory.InMemoryTransactionService
 
ThriftClientProvider - Interface in org.apache.tephra.distributed
This interface is used to provide thrift tx service clients: there is only one (singleton) tx service per JVM, but many threads may use it concurrently.
ThriftRPCServer<T extends RPCServiceHandler,I> - Class in org.apache.tephra.rpc
 
ThriftRPCServer.Builder<I> - Class in org.apache.tephra.rpc
Builder for creating instance of ThriftRPCServer.
time - Variable in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_args
 
timeout - Variable in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortTimeout_args
 
timeout - Variable in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_args
 
TimeRegions - Class in org.apache.tephra.hbase.txprune
Contains information on the set of transactional regions recorded at a given time
TimeRegions(long, SortedSet<byte[]>) - Constructor for class org.apache.tephra.hbase.txprune.TimeRegions
 
timestamp - Variable in class org.apache.tephra.persist.AbstractTransactionLog
 
TInvalidTruncateTimeException - Exception in org.apache.tephra.distributed.thrift
 
TInvalidTruncateTimeException() - Constructor for exception org.apache.tephra.distributed.thrift.TInvalidTruncateTimeException
 
TInvalidTruncateTimeException(String) - Constructor for exception org.apache.tephra.distributed.thrift.TInvalidTruncateTimeException
 
TInvalidTruncateTimeException(TInvalidTruncateTimeException) - Constructor for exception org.apache.tephra.distributed.thrift.TInvalidTruncateTimeException
Performs a deep copy on other.
TInvalidTruncateTimeException._Fields - Enum in org.apache.tephra.distributed.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
toByteArray() - Method in class org.apache.tephra.hbase.coprocessor.CellSkipFilter
 
toByteArray() - Method in class org.apache.tephra.hbase.coprocessor.TransactionVisibilityFilter
 
toRawList() - Method in class org.apache.tephra.manager.InvalidTxList
 
toSortedArray() - Method in class org.apache.tephra.manager.InvalidTxList
 
toString() - Method in class co.cask.tephra.persist.TransactionEdit
Deprecated.
 
toString() - Method in class org.apache.tephra.ChangeId
 
toString() - Method in class org.apache.tephra.distributed.PooledClientProvider
 
toString() - Method in class org.apache.tephra.distributed.RetryNTimes.Provider
 
toString() - Method in class org.apache.tephra.distributed.RetryWithBackoff.Provider
 
toString() - Method in class org.apache.tephra.distributed.SingleUseClientProvider
 
toString() - Method in class org.apache.tephra.distributed.ThreadLocalClientProvider
 
toString() - Method in class org.apache.tephra.distributed.thrift.TBoolean
 
toString() - Method in exception org.apache.tephra.distributed.thrift.TGenericException
 
toString() - Method in exception org.apache.tephra.distributed.thrift.TInvalidTruncateTimeException
 
toString() - Method in class org.apache.tephra.distributed.thrift.TTransaction
 
toString() - Method in exception org.apache.tephra.distributed.thrift.TTransactionCouldNotTakeSnapshotException
 
toString() - Method in exception org.apache.tephra.distributed.thrift.TTransactionNotInProgressException
 
toString() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.abortTx_args
 
toString() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.abortTx_result
 
toString() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_args
 
toString() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_result
 
toString() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_args
 
toString() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_result
 
toString() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_args
 
toString() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_result
 
toString() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.getSnapshot_args
 
toString() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.getSnapshot_result
 
toString() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidateTx_args
 
toString() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidateTx_result
 
toString() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidTxSize_args
 
toString() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidTxSize_result
 
toString() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.resetState_args
 
toString() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.resetState_result
 
toString() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startLong_args
 
toString() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startLong_result
 
toString() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShort_args
 
toString() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShort_result
 
toString() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortTimeout_args
 
toString() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortTimeout_result
 
toString() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_args
 
toString() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_result
 
toString() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.status_args
 
toString() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.status_result
 
toString() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTx_args
 
toString() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTx_result
 
toString() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_args
 
toString() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_result
 
toString() - Method in class org.apache.tephra.hbase.txprune.TimeRegions
 
toString() - Method in class org.apache.tephra.persist.TransactionEdit
 
toString() - Method in class org.apache.tephra.persist.TransactionSnapshot
 
toString() - Method in class org.apache.tephra.Transaction
 
toString() - Method in class org.apache.tephra.TransactionManager.InProgressTx
 
toString() - Method in class org.apache.tephra.txprune.RegionPruneInfo
 
Transaction - Class in org.apache.tephra
Transaction details
Transaction(long, long, long[], long[], long) - Constructor for class org.apache.tephra.Transaction
Creates a new short transaction.
Transaction(long, long, long[], long[], long, TransactionType) - Constructor for class org.apache.tephra.Transaction
Creates a new transaction.
Transaction(long, long, long, long[], long[], long, TransactionType, long[], Transaction.VisibilityLevel) - Constructor for class org.apache.tephra.Transaction
Creates a new transaction.
Transaction(Transaction, long, long[]) - Constructor for class org.apache.tephra.Transaction
Creates a new transaction for a checkpoint operation, copying all members from the original transaction, with the updated checkpoint write pointers.
Transaction.VisibilityLevel - Enum in org.apache.tephra
Defines the possible visibility levels for read operations.
TransactionAdmin - Class in org.apache.tephra
Allows calling some methods on TransactionManager from command line.
TransactionAdmin(PrintStream, PrintStream) - Constructor for class org.apache.tephra.TransactionAdmin
 
TransactionAware - Interface in org.apache.tephra
Interface to be implemented by a component that interacts with transaction logic.
TransactionAwareHTable - Class in org.apache.tephra.hbase
A Transaction Aware HTable implementation for HBase 0.96.
TransactionAwareHTable(HTableInterface) - Constructor for class org.apache.tephra.hbase.TransactionAwareHTable
Create a transactional aware instance of the passed HTable
TransactionAwareHTable(HTableInterface, TxConstants.ConflictDetection) - Constructor for class org.apache.tephra.hbase.TransactionAwareHTable
Create a transactional aware instance of the passed HTable
TransactionAwareHTable(HTableInterface, boolean) - Constructor for class org.apache.tephra.hbase.TransactionAwareHTable
Create a transactional aware instance of the passed HTable, with the option of allowing non-transactional operations.
TransactionAwareHTable(HTableInterface, TxConstants.ConflictDetection, boolean) - Constructor for class org.apache.tephra.hbase.TransactionAwareHTable
Create a transactional aware instance of the passed HTable, with the option of allowing non-transactional operations.
TransactionAwares - Class in org.apache.tephra
Utility class that provides handy methods for working with TransactionAware classes and their instances.
TransactionClientModule - Class in org.apache.tephra.runtime
Provides Guice binding for ThriftClientProvider.
TransactionClientModule() - Constructor for class org.apache.tephra.runtime.TransactionClientModule
 
TransactionCodec - Class in org.apache.tephra
Handles serialization and deserialization of Transaction instances to and from byte[].
TransactionCodec() - Constructor for class org.apache.tephra.TransactionCodec
 
TransactionConflictException - Exception in org.apache.tephra
Thrown to indicate transaction conflict occurred when trying to commit a transaction.
TransactionConflictException(String) - Constructor for exception org.apache.tephra.TransactionConflictException
 
TransactionConflictException(String, Throwable) - Constructor for exception org.apache.tephra.TransactionConflictException
 
TransactionContext - Class in org.apache.tephra
Utility class that encapsulates the transaction life cycle over a given set of transaction-aware datasets.
TransactionContext(TransactionSystemClient, TransactionAware...) - Constructor for class org.apache.tephra.TransactionContext
 
TransactionContext(TransactionSystemClient, Iterable<TransactionAware>) - Constructor for class org.apache.tephra.TransactionContext
 
TransactionConverterUtils - Class in org.apache.tephra.distributed
Utility methods to convert to thrift and back.
TransactionConverterUtils() - Constructor for class org.apache.tephra.distributed.TransactionConverterUtils
 
TransactionCouldNotTakeSnapshotException - Exception in org.apache.tephra
Throw when taking a snapshot fails.
TransactionCouldNotTakeSnapshotException(String) - Constructor for exception org.apache.tephra.TransactionCouldNotTakeSnapshotException
 
TransactionEdit - Class in co.cask.tephra.persist
Deprecated.
TransactionEdit() - Constructor for class co.cask.tephra.persist.TransactionEdit
Deprecated.
 
TransactionEdit - Class in org.apache.tephra.persist
Represents a transaction state change in the TransactionLog.
TransactionEdit() - Constructor for class org.apache.tephra.persist.TransactionEdit
 
TransactionEdit.State - Enum in co.cask.tephra.persist
Deprecated.
The possible state changes for a transaction.
TransactionEdit.State - Enum in org.apache.tephra.persist
The possible state changes for a transaction.
TransactionEditCodecs - Class in co.cask.tephra.persist
Deprecated.
TransactionEditCodecs() - Constructor for class co.cask.tephra.persist.TransactionEditCodecs
Deprecated.
 
TransactionEditCodecs - Class in org.apache.tephra.persist
Utilities to handle encoding and decoding of TransactionEdit entries, while maintaining compatibility with older versions of the serialized data.
TransactionEditCodecs() - Constructor for class org.apache.tephra.persist.TransactionEditCodecs
 
TransactionExecutor - Interface in org.apache.tephra
Utility that wraps the execution of a function into the context of a transaction.
TransactionExecutor.Function<I,O> - Interface in org.apache.tephra
A function is a class with a single method that takes an argument and returns a result.
TransactionExecutor.Procedure<I> - Interface in org.apache.tephra
A procedure is a class with a single void method that takes an argument.
TransactionExecutor.Subroutine - Interface in org.apache.tephra
A subroutine is a class with a single void method without arguments.
TransactionExecutorFactory - Interface in org.apache.tephra
A factory for transaction executors.
TransactionFailureException - Exception in org.apache.tephra
Thrown to indicate execution of a transaction failed.
TransactionFailureException(String) - Constructor for exception org.apache.tephra.TransactionFailureException
 
TransactionFailureException(String, Throwable) - Constructor for exception org.apache.tephra.TransactionFailureException
 
TransactionFilters - Class in org.apache.tephra.hbase.coprocessor
Factory class for providing Filter instances.
TransactionFilters() - Constructor for class org.apache.tephra.hbase.coprocessor.TransactionFilters
 
transactionId - Variable in class org.apache.tephra.distributed.thrift.TTransaction
 
TransactionInMemoryModule - Class in org.apache.tephra.runtime
Guice bindings for running completely in-memory (no persistence).
TransactionInMemoryModule() - Constructor for class org.apache.tephra.runtime.TransactionInMemoryModule
 
TransactionLog - Interface in org.apache.tephra.persist
Represents a log of transaction state changes.
TransactionLogReader - Interface in org.apache.tephra.persist
Represents a reader for TransactionLog instances.
TransactionLogWriter - Interface in org.apache.tephra.persist
Common interface for transaction log writers used by classes extending AbstractTransactionLog.
TransactionManager - Class in org.apache.tephra
This is the central place to manage all active transactions in the system.
TransactionManager(Configuration) - Constructor for class org.apache.tephra.TransactionManager
 
TransactionManager(Configuration, TransactionStateStorage, MetricsCollector) - Constructor for class org.apache.tephra.TransactionManager
 
TransactionManager.InProgressTx - Class in org.apache.tephra
Represents some of the info on in-progress tx
TransactionManager.InProgressTx(long, long, TransactionManager.InProgressType) - Constructor for class org.apache.tephra.TransactionManager.InProgressTx
 
TransactionManager.InProgressTx(long, long, TransactionManager.InProgressType, LongArrayList) - Constructor for class org.apache.tephra.TransactionManager.InProgressTx
 
TransactionManager.InProgressTx(long, long) - Constructor for class org.apache.tephra.TransactionManager.InProgressTx
Deprecated.
TransactionManager.InProgressType - Enum in org.apache.tephra
Type of in-progress transaction.
TransactionModules - Class in org.apache.tephra.runtime
Provides access to Google Guice modules for in-memory, single-node, and distributed operation.
TransactionModules() - Constructor for class org.apache.tephra.runtime.TransactionModules
 
TransactionNotInProgressException - Exception in org.apache.tephra
Thrown when transaction has timed out.
TransactionNotInProgressException(String) - Constructor for exception org.apache.tephra.TransactionNotInProgressException
 
TransactionProcessor - Class in org.apache.tephra.hbase.coprocessor
org.apache.hadoop.hbase.coprocessor.RegionObserver coprocessor that handles server-side processing for transactions: applies filtering to exclude data from invalid and in-progress transactions overrides the scanner returned for flush and compaction to drop data written by invalidated transactions, or expired due to TTL.
TransactionProcessor() - Constructor for class org.apache.tephra.hbase.coprocessor.TransactionProcessor
 
TransactionPruningPlugin - Interface in org.apache.tephra.txprune
Interface to manage the invalid transaction list.
TransactionPruningRunnable - Class in org.apache.tephra.txprune
This class executes one run of transaction pruning every time it is invoked.
TransactionPruningRunnable(TransactionManager, Map<String, TransactionPruningPlugin>, long, long) - Constructor for class org.apache.tephra.txprune.TransactionPruningRunnable
 
TransactionPruningService - Class in org.apache.tephra.txprune
Service to prune the invalid list periodically.
TransactionPruningService(Configuration, TransactionManager) - Constructor for class org.apache.tephra.txprune.TransactionPruningService
 
TransactionService - Class in org.apache.tephra.distributed
 
TransactionService(Configuration, ZKClient, DiscoveryService, Provider<TransactionManager>) - Constructor for class org.apache.tephra.distributed.TransactionService
 
TransactionServiceClient - Class in org.apache.tephra.distributed
A tx service client
TransactionServiceClient(Configuration, ThriftClientProvider) - Constructor for class org.apache.tephra.distributed.TransactionServiceClient
Create from a configuration.
TransactionServiceMain - Class in org.apache.tephra
Driver class to start and stop tx in distributed mode.
TransactionServiceMain() - Constructor for class org.apache.tephra.TransactionServiceMain
 
TransactionServiceMain(Configuration) - Constructor for class org.apache.tephra.TransactionServiceMain
 
TransactionServiceThriftClient - Class in org.apache.tephra.distributed
This class is a wrapper around the thrift tx service client, it takes Operations, converts them into thrift objects, calls the thrift client, and converts the results back to data fabric classes.
TransactionServiceThriftClient(TTransport) - Constructor for class org.apache.tephra.distributed.TransactionServiceThriftClient
Constructor from an existing, connected thrift transport.
TransactionServiceThriftHandler - Class in org.apache.tephra.distributed
The implementation of a thrift service for tx service.
TransactionServiceThriftHandler(TransactionManager) - Constructor for class org.apache.tephra.distributed.TransactionServiceThriftHandler
 
TransactionSnapshot - Class in org.apache.tephra.persist
Represents an in-memory snapshot of the full transaction state.
TransactionSnapshot(long, long, long, Collection<Long>, NavigableMap<Long, TransactionManager.InProgressTx>, Map<Long, Set<ChangeId>>, Map<Long, Set<ChangeId>>) - Constructor for class org.apache.tephra.persist.TransactionSnapshot
 
TransactionSnapshot(long, long, long, Collection<Long>, NavigableMap<Long, TransactionManager.InProgressTx>) - Constructor for class org.apache.tephra.persist.TransactionSnapshot
 
TransactionStateCache - Class in org.apache.tephra.coprocessor
Periodically refreshes transaction state from the latest stored snapshot.
TransactionStateCache() - Constructor for class org.apache.tephra.coprocessor.TransactionStateCache
 
TransactionStateCacheSupplier - Class in org.apache.tephra.coprocessor
Supplies instances of TransactionStateCache implementations.
TransactionStateCacheSupplier(Configuration) - Constructor for class org.apache.tephra.coprocessor.TransactionStateCacheSupplier
 
TransactionStateStorage - Interface in org.apache.tephra.persist
Defines the common contract for persisting transaction state changes.
TransactionStateStorageProvider - Class in org.apache.tephra.runtime
A provider for TransactionStateStorage that provides different TransactionStateStorage implementation based on configuration.
TransactionSystemClient - Interface in org.apache.tephra
Client talking to transaction system.
TransactionType - Enum in org.apache.tephra
Type of transaction.
TransactionVisibilityFilter - Class in org.apache.tephra.hbase.coprocessor
Applies filtering of data based on transactional visibility (HBase 0.96+ specific version).
TransactionVisibilityFilter(Transaction, Map<byte[], Long>, boolean, ScanType) - Constructor for class org.apache.tephra.hbase.coprocessor.TransactionVisibilityFilter
Creates a new Filter for returning data only from visible transactions.
TransactionVisibilityFilter(Transaction, Map<byte[], Long>, boolean, ScanType, Filter) - Constructor for class org.apache.tephra.hbase.coprocessor.TransactionVisibilityFilter
Creates a new Filter for returning data only from visible transactions.
TransactionVisibilityState - Interface in org.apache.tephra.persist
Transaction Visibility state contains information required by TransactionProcessor CoProcessor to determine cell visibility.
transformCell(Cell) - Method in class org.apache.tephra.hbase.coprocessor.CellSkipFilter
 
transformCell(Cell) - Method in class org.apache.tephra.hbase.coprocessor.TransactionVisibilityFilter
 
triggerShutdown() - Method in class org.apache.tephra.rpc.ThriftRPCServer
 
truncateInvalidTx(Set<Long>, AsyncMethodCallback<TTransactionServer.AsyncClient.truncateInvalidTx_call>) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.AsyncClient
 
truncateInvalidTx(Set<Long>, AsyncMethodCallback<TTransactionServer.AsyncClient.truncateInvalidTx_call>) - Method in interface org.apache.tephra.distributed.thrift.TTransactionServer.AsyncIface
 
truncateInvalidTx(Set<Long>) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Client
 
truncateInvalidTx(Set<Long>) - Method in interface org.apache.tephra.distributed.thrift.TTransactionServer.Iface
 
truncateInvalidTx(Set<Long>) - Method in class org.apache.tephra.distributed.TransactionServiceClient
 
truncateInvalidTx(Set<Long>) - Method in class org.apache.tephra.distributed.TransactionServiceThriftClient
 
truncateInvalidTx(Set<Long>) - Method in class org.apache.tephra.distributed.TransactionServiceThriftHandler
 
truncateInvalidTx(Set<Long>) - Method in class org.apache.tephra.inmemory.DetachedTxSystemClient
 
truncateInvalidTx(Set<Long>) - Method in class org.apache.tephra.inmemory.InMemoryTxSystemClient
 
truncateInvalidTx(Set<Long>) - Method in class org.apache.tephra.inmemory.MinimalTxSystemClient
 
truncateInvalidTx(Set<Long>) - Method in class org.apache.tephra.TransactionManager
Removes the given transaction ids from the invalid list.
truncateInvalidTx(Set<Long>) - Method in interface org.apache.tephra.TransactionSystemClient
Removes the given transaction ids from the invalid list.
truncateInvalidTxBefore(long, AsyncMethodCallback<TTransactionServer.AsyncClient.truncateInvalidTxBefore_call>) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.AsyncClient
 
truncateInvalidTxBefore(long, AsyncMethodCallback<TTransactionServer.AsyncClient.truncateInvalidTxBefore_call>) - Method in interface org.apache.tephra.distributed.thrift.TTransactionServer.AsyncIface
 
truncateInvalidTxBefore(long) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.Client
 
truncateInvalidTxBefore(long) - Method in interface org.apache.tephra.distributed.thrift.TTransactionServer.Iface
 
truncateInvalidTxBefore(long) - Method in class org.apache.tephra.distributed.TransactionServiceClient
 
truncateInvalidTxBefore(long) - Method in class org.apache.tephra.distributed.TransactionServiceThriftClient
 
truncateInvalidTxBefore(long) - Method in class org.apache.tephra.distributed.TransactionServiceThriftHandler
 
truncateInvalidTxBefore(long) - Method in class org.apache.tephra.inmemory.DetachedTxSystemClient
 
truncateInvalidTxBefore(long) - Method in class org.apache.tephra.inmemory.InMemoryTxSystemClient
 
truncateInvalidTxBefore(long) - Method in class org.apache.tephra.inmemory.MinimalTxSystemClient
 
truncateInvalidTxBefore(long) - Method in class org.apache.tephra.TransactionManager
Removes all transaction ids started before the given time from invalid list.
truncateInvalidTxBefore(long) - Method in interface org.apache.tephra.TransactionSystemClient
Removes all transaction ids started before the given time from invalid list.
TThreadedSelectorServerWithFix - Class in org.apache.thrift.server
A Half-Sync/Half-Async server with a separate pool of threads to handle non-blocking I/O.
TThreadedSelectorServerWithFix(TThreadedSelectorServerWithFix.Args) - Constructor for class org.apache.thrift.server.TThreadedSelectorServerWithFix
Create the server with the specified Args configuration
TThreadedSelectorServerWithFix.AcceptThread - Class in org.apache.thrift.server
The thread that selects on the server transport (listen socket) and accepts new connections to hand off to the IO selector threads
TThreadedSelectorServerWithFix.AcceptThread(TNonblockingServerTransport, TThreadedSelectorServerWithFix.SelectorThreadLoadBalancer) - Constructor for class org.apache.thrift.server.TThreadedSelectorServerWithFix.AcceptThread
Set up the AcceptThead
TThreadedSelectorServerWithFix.Args - Class in org.apache.thrift.server
 
TThreadedSelectorServerWithFix.Args(TNonblockingServerTransport) - Constructor for class org.apache.thrift.server.TThreadedSelectorServerWithFix.Args
 
TThreadedSelectorServerWithFix.Args.AcceptPolicy - Enum in org.apache.thrift.server
Determines the strategy for handling new accepted connections.
TThreadedSelectorServerWithFix.SelectorThread - Class in org.apache.thrift.server
The SelectorThread(s) will be doing all the selecting on accepted active connections.
TThreadedSelectorServerWithFix.SelectorThread() - Constructor for class org.apache.thrift.server.TThreadedSelectorServerWithFix.SelectorThread
Set up the SelectorThread with an unbounded queue for incoming accepts.
TThreadedSelectorServerWithFix.SelectorThread(int) - Constructor for class org.apache.thrift.server.TThreadedSelectorServerWithFix.SelectorThread
Set up the SelectorThread with an bounded queue for incoming accepts.
TThreadedSelectorServerWithFix.SelectorThread(BlockingQueue<TNonblockingTransport>) - Constructor for class org.apache.thrift.server.TThreadedSelectorServerWithFix.SelectorThread
Set up the SelectorThread with a specified queue for connections.
TThreadedSelectorServerWithFix.SelectorThreadLoadBalancer - Class in org.apache.thrift.server
A round robin load balancer for choosing selector threads for new connections.
TThreadedSelectorServerWithFix.SelectorThreadLoadBalancer(Collection<T>) - Constructor for class org.apache.thrift.server.TThreadedSelectorServerWithFix.SelectorThreadLoadBalancer
 
ttlByFamily - Variable in class org.apache.tephra.hbase.coprocessor.TransactionProcessor
 
TTransaction - Class in org.apache.tephra.distributed.thrift
 
TTransaction() - Constructor for class org.apache.tephra.distributed.thrift.TTransaction
 
TTransaction(long, long, List<Long>, List<Long>, long, TTransactionType, long, List<Long>, TVisibilityLevel) - Constructor for class org.apache.tephra.distributed.thrift.TTransaction
 
TTransaction(TTransaction) - Constructor for class org.apache.tephra.distributed.thrift.TTransaction
Performs a deep copy on other.
TTransaction._Fields - Enum in org.apache.tephra.distributed.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TTransactionCouldNotTakeSnapshotException - Exception in org.apache.tephra.distributed.thrift
 
TTransactionCouldNotTakeSnapshotException() - Constructor for exception org.apache.tephra.distributed.thrift.TTransactionCouldNotTakeSnapshotException
 
TTransactionCouldNotTakeSnapshotException(String) - Constructor for exception org.apache.tephra.distributed.thrift.TTransactionCouldNotTakeSnapshotException
 
TTransactionCouldNotTakeSnapshotException(TTransactionCouldNotTakeSnapshotException) - Constructor for exception org.apache.tephra.distributed.thrift.TTransactionCouldNotTakeSnapshotException
Performs a deep copy on other.
TTransactionCouldNotTakeSnapshotException._Fields - Enum in org.apache.tephra.distributed.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TTransactionNotInProgressException - Exception in org.apache.tephra.distributed.thrift
 
TTransactionNotInProgressException() - Constructor for exception org.apache.tephra.distributed.thrift.TTransactionNotInProgressException
 
TTransactionNotInProgressException(String) - Constructor for exception org.apache.tephra.distributed.thrift.TTransactionNotInProgressException
 
TTransactionNotInProgressException(TTransactionNotInProgressException) - Constructor for exception org.apache.tephra.distributed.thrift.TTransactionNotInProgressException
Performs a deep copy on other.
TTransactionNotInProgressException._Fields - Enum in org.apache.tephra.distributed.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TTransactionServer - Class in org.apache.tephra.distributed.thrift
 
TTransactionServer() - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer
 
TTransactionServer.abortTx_args - Class in org.apache.tephra.distributed.thrift
 
TTransactionServer.abortTx_args() - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.abortTx_args
 
TTransactionServer.abortTx_args(TTransaction) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.abortTx_args
 
TTransactionServer.abortTx_args(TTransactionServer.abortTx_args) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.abortTx_args
Performs a deep copy on other.
TTransactionServer.abortTx_args._Fields - Enum in org.apache.tephra.distributed.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TTransactionServer.abortTx_result - Class in org.apache.tephra.distributed.thrift
 
TTransactionServer.abortTx_result() - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.abortTx_result
 
TTransactionServer.abortTx_result(TTransactionServer.abortTx_result) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.abortTx_result
Performs a deep copy on other.
TTransactionServer.abortTx_result._Fields - Enum in org.apache.tephra.distributed.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TTransactionServer.AsyncClient - Class in org.apache.tephra.distributed.thrift
 
TTransactionServer.AsyncClient(TProtocolFactory, TAsyncClientManager, TNonblockingTransport) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.AsyncClient
 
TTransactionServer.AsyncClient.abortTx_call - Class in org.apache.tephra.distributed.thrift
 
TTransactionServer.AsyncClient.abortTx_call(TTransaction, AsyncMethodCallback<TTransactionServer.AsyncClient.abortTx_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.AsyncClient.abortTx_call
 
TTransactionServer.AsyncClient.canCommitTx_call - Class in org.apache.tephra.distributed.thrift
 
TTransactionServer.AsyncClient.canCommitTx_call(TTransaction, Set<ByteBuffer>, AsyncMethodCallback<TTransactionServer.AsyncClient.canCommitTx_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.AsyncClient.canCommitTx_call
 
TTransactionServer.AsyncClient.checkpoint_call - Class in org.apache.tephra.distributed.thrift
 
TTransactionServer.AsyncClient.checkpoint_call(TTransaction, AsyncMethodCallback<TTransactionServer.AsyncClient.checkpoint_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.AsyncClient.checkpoint_call
 
TTransactionServer.AsyncClient.commitTx_call - Class in org.apache.tephra.distributed.thrift
 
TTransactionServer.AsyncClient.commitTx_call(TTransaction, AsyncMethodCallback<TTransactionServer.AsyncClient.commitTx_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.AsyncClient.commitTx_call
 
TTransactionServer.AsyncClient.Factory - Class in org.apache.tephra.distributed.thrift
 
TTransactionServer.AsyncClient.Factory(TAsyncClientManager, TProtocolFactory) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.AsyncClient.Factory
 
TTransactionServer.AsyncClient.getSnapshot_call - Class in org.apache.tephra.distributed.thrift
 
TTransactionServer.AsyncClient.getSnapshot_call(AsyncMethodCallback<TTransactionServer.AsyncClient.getSnapshot_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.AsyncClient.getSnapshot_call
 
TTransactionServer.AsyncClient.invalidateTx_call - Class in org.apache.tephra.distributed.thrift
 
TTransactionServer.AsyncClient.invalidateTx_call(long, AsyncMethodCallback<TTransactionServer.AsyncClient.invalidateTx_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.AsyncClient.invalidateTx_call
 
TTransactionServer.AsyncClient.invalidTxSize_call - Class in org.apache.tephra.distributed.thrift
 
TTransactionServer.AsyncClient.invalidTxSize_call(AsyncMethodCallback<TTransactionServer.AsyncClient.invalidTxSize_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.AsyncClient.invalidTxSize_call
 
TTransactionServer.AsyncClient.resetState_call - Class in org.apache.tephra.distributed.thrift
 
TTransactionServer.AsyncClient.resetState_call(AsyncMethodCallback<TTransactionServer.AsyncClient.resetState_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.AsyncClient.resetState_call
 
TTransactionServer.AsyncClient.startLong_call - Class in org.apache.tephra.distributed.thrift
 
TTransactionServer.AsyncClient.startLong_call(AsyncMethodCallback<TTransactionServer.AsyncClient.startLong_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.AsyncClient.startLong_call
 
TTransactionServer.AsyncClient.startShort_call - Class in org.apache.tephra.distributed.thrift
 
TTransactionServer.AsyncClient.startShort_call(AsyncMethodCallback<TTransactionServer.AsyncClient.startShort_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.AsyncClient.startShort_call
 
TTransactionServer.AsyncClient.startShortTimeout_call - Class in org.apache.tephra.distributed.thrift
 
TTransactionServer.AsyncClient.startShortTimeout_call(int, AsyncMethodCallback<TTransactionServer.AsyncClient.startShortTimeout_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.AsyncClient.startShortTimeout_call
 
TTransactionServer.AsyncClient.startShortWithTimeout_call - Class in org.apache.tephra.distributed.thrift
 
TTransactionServer.AsyncClient.startShortWithTimeout_call(int, AsyncMethodCallback<TTransactionServer.AsyncClient.startShortWithTimeout_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.AsyncClient.startShortWithTimeout_call
 
TTransactionServer.AsyncClient.status_call - Class in org.apache.tephra.distributed.thrift
 
TTransactionServer.AsyncClient.status_call(AsyncMethodCallback<TTransactionServer.AsyncClient.status_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.AsyncClient.status_call
 
TTransactionServer.AsyncClient.truncateInvalidTx_call - Class in org.apache.tephra.distributed.thrift
 
TTransactionServer.AsyncClient.truncateInvalidTx_call(Set<Long>, AsyncMethodCallback<TTransactionServer.AsyncClient.truncateInvalidTx_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.AsyncClient.truncateInvalidTx_call
 
TTransactionServer.AsyncClient.truncateInvalidTxBefore_call - Class in org.apache.tephra.distributed.thrift
 
TTransactionServer.AsyncClient.truncateInvalidTxBefore_call(long, AsyncMethodCallback<TTransactionServer.AsyncClient.truncateInvalidTxBefore_call>, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.AsyncClient.truncateInvalidTxBefore_call
 
TTransactionServer.AsyncIface - Interface in org.apache.tephra.distributed.thrift
 
TTransactionServer.canCommitTx_args - Class in org.apache.tephra.distributed.thrift
 
TTransactionServer.canCommitTx_args() - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_args
 
TTransactionServer.canCommitTx_args(TTransaction, Set<ByteBuffer>) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_args
 
TTransactionServer.canCommitTx_args(TTransactionServer.canCommitTx_args) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_args
Performs a deep copy on other.
TTransactionServer.canCommitTx_args._Fields - Enum in org.apache.tephra.distributed.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TTransactionServer.canCommitTx_result - Class in org.apache.tephra.distributed.thrift
 
TTransactionServer.canCommitTx_result() - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_result
 
TTransactionServer.canCommitTx_result(TBoolean, TTransactionNotInProgressException) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_result
 
TTransactionServer.canCommitTx_result(TTransactionServer.canCommitTx_result) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_result
Performs a deep copy on other.
TTransactionServer.canCommitTx_result._Fields - Enum in org.apache.tephra.distributed.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TTransactionServer.checkpoint_args - Class in org.apache.tephra.distributed.thrift
 
TTransactionServer.checkpoint_args() - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_args
 
TTransactionServer.checkpoint_args(TTransaction) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_args
 
TTransactionServer.checkpoint_args(TTransactionServer.checkpoint_args) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_args
Performs a deep copy on other.
TTransactionServer.checkpoint_args._Fields - Enum in org.apache.tephra.distributed.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TTransactionServer.checkpoint_result - Class in org.apache.tephra.distributed.thrift
 
TTransactionServer.checkpoint_result() - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_result
 
TTransactionServer.checkpoint_result(TTransaction, TTransactionNotInProgressException) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_result
 
TTransactionServer.checkpoint_result(TTransactionServer.checkpoint_result) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_result
Performs a deep copy on other.
TTransactionServer.checkpoint_result._Fields - Enum in org.apache.tephra.distributed.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TTransactionServer.Client - Class in org.apache.tephra.distributed.thrift
 
TTransactionServer.Client(TProtocol) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.Client
 
TTransactionServer.Client(TProtocol, TProtocol) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.Client
 
TTransactionServer.Client.Factory - Class in org.apache.tephra.distributed.thrift
 
TTransactionServer.Client.Factory() - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.Client.Factory
 
TTransactionServer.commitTx_args - Class in org.apache.tephra.distributed.thrift
 
TTransactionServer.commitTx_args() - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_args
 
TTransactionServer.commitTx_args(TTransaction) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_args
 
TTransactionServer.commitTx_args(TTransactionServer.commitTx_args) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_args
Performs a deep copy on other.
TTransactionServer.commitTx_args._Fields - Enum in org.apache.tephra.distributed.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TTransactionServer.commitTx_result - Class in org.apache.tephra.distributed.thrift
 
TTransactionServer.commitTx_result() - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_result
 
TTransactionServer.commitTx_result(TBoolean, TTransactionNotInProgressException) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_result
 
TTransactionServer.commitTx_result(TTransactionServer.commitTx_result) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_result
Performs a deep copy on other.
TTransactionServer.commitTx_result._Fields - Enum in org.apache.tephra.distributed.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TTransactionServer.getSnapshot_args - Class in org.apache.tephra.distributed.thrift
 
TTransactionServer.getSnapshot_args() - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.getSnapshot_args
 
TTransactionServer.getSnapshot_args(TTransactionServer.getSnapshot_args) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.getSnapshot_args
Performs a deep copy on other.
TTransactionServer.getSnapshot_args._Fields - Enum in org.apache.tephra.distributed.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TTransactionServer.getSnapshot_result - Class in org.apache.tephra.distributed.thrift
 
TTransactionServer.getSnapshot_result() - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.getSnapshot_result
 
TTransactionServer.getSnapshot_result(ByteBuffer, TTransactionCouldNotTakeSnapshotException) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.getSnapshot_result
 
TTransactionServer.getSnapshot_result(TTransactionServer.getSnapshot_result) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.getSnapshot_result
Performs a deep copy on other.
TTransactionServer.getSnapshot_result._Fields - Enum in org.apache.tephra.distributed.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TTransactionServer.Iface - Interface in org.apache.tephra.distributed.thrift
 
TTransactionServer.invalidateTx_args - Class in org.apache.tephra.distributed.thrift
 
TTransactionServer.invalidateTx_args() - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.invalidateTx_args
 
TTransactionServer.invalidateTx_args(long) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.invalidateTx_args
 
TTransactionServer.invalidateTx_args(TTransactionServer.invalidateTx_args) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.invalidateTx_args
Performs a deep copy on other.
TTransactionServer.invalidateTx_args._Fields - Enum in org.apache.tephra.distributed.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TTransactionServer.invalidateTx_result - Class in org.apache.tephra.distributed.thrift
 
TTransactionServer.invalidateTx_result() - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.invalidateTx_result
 
TTransactionServer.invalidateTx_result(boolean) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.invalidateTx_result
 
TTransactionServer.invalidateTx_result(TTransactionServer.invalidateTx_result) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.invalidateTx_result
Performs a deep copy on other.
TTransactionServer.invalidateTx_result._Fields - Enum in org.apache.tephra.distributed.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TTransactionServer.invalidTxSize_args - Class in org.apache.tephra.distributed.thrift
 
TTransactionServer.invalidTxSize_args() - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.invalidTxSize_args
 
TTransactionServer.invalidTxSize_args(TTransactionServer.invalidTxSize_args) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.invalidTxSize_args
Performs a deep copy on other.
TTransactionServer.invalidTxSize_args._Fields - Enum in org.apache.tephra.distributed.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TTransactionServer.invalidTxSize_result - Class in org.apache.tephra.distributed.thrift
 
TTransactionServer.invalidTxSize_result() - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.invalidTxSize_result
 
TTransactionServer.invalidTxSize_result(int) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.invalidTxSize_result
 
TTransactionServer.invalidTxSize_result(TTransactionServer.invalidTxSize_result) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.invalidTxSize_result
Performs a deep copy on other.
TTransactionServer.invalidTxSize_result._Fields - Enum in org.apache.tephra.distributed.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TTransactionServer.Processor<I extends TTransactionServer.Iface> - Class in org.apache.tephra.distributed.thrift
 
TTransactionServer.Processor(I) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.Processor
 
TTransactionServer.Processor(I, Map<String, ProcessFunction<I, ? extends TBase>>) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.Processor
 
TTransactionServer.Processor.abortTx<I extends TTransactionServer.Iface> - Class in org.apache.tephra.distributed.thrift
 
TTransactionServer.Processor.abortTx() - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.Processor.abortTx
 
TTransactionServer.Processor.canCommitTx<I extends TTransactionServer.Iface> - Class in org.apache.tephra.distributed.thrift
 
TTransactionServer.Processor.canCommitTx() - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.Processor.canCommitTx
 
TTransactionServer.Processor.checkpoint<I extends TTransactionServer.Iface> - Class in org.apache.tephra.distributed.thrift
 
TTransactionServer.Processor.checkpoint() - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.Processor.checkpoint
 
TTransactionServer.Processor.commitTx<I extends TTransactionServer.Iface> - Class in org.apache.tephra.distributed.thrift
 
TTransactionServer.Processor.commitTx() - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.Processor.commitTx
 
TTransactionServer.Processor.getSnapshot<I extends TTransactionServer.Iface> - Class in org.apache.tephra.distributed.thrift
 
TTransactionServer.Processor.getSnapshot() - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.Processor.getSnapshot
 
TTransactionServer.Processor.invalidateTx<I extends TTransactionServer.Iface> - Class in org.apache.tephra.distributed.thrift
 
TTransactionServer.Processor.invalidateTx() - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.Processor.invalidateTx
 
TTransactionServer.Processor.invalidTxSize<I extends TTransactionServer.Iface> - Class in org.apache.tephra.distributed.thrift
 
TTransactionServer.Processor.invalidTxSize() - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.Processor.invalidTxSize
 
TTransactionServer.Processor.resetState<I extends TTransactionServer.Iface> - Class in org.apache.tephra.distributed.thrift
 
TTransactionServer.Processor.resetState() - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.Processor.resetState
 
TTransactionServer.Processor.startLong<I extends TTransactionServer.Iface> - Class in org.apache.tephra.distributed.thrift
 
TTransactionServer.Processor.startLong() - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.Processor.startLong
 
TTransactionServer.Processor.startShort<I extends TTransactionServer.Iface> - Class in org.apache.tephra.distributed.thrift
 
TTransactionServer.Processor.startShort() - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.Processor.startShort
 
TTransactionServer.Processor.startShortTimeout<I extends TTransactionServer.Iface> - Class in org.apache.tephra.distributed.thrift
 
TTransactionServer.Processor.startShortTimeout() - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.Processor.startShortTimeout
 
TTransactionServer.Processor.startShortWithTimeout<I extends TTransactionServer.Iface> - Class in org.apache.tephra.distributed.thrift
 
TTransactionServer.Processor.startShortWithTimeout() - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.Processor.startShortWithTimeout
 
TTransactionServer.Processor.status<I extends TTransactionServer.Iface> - Class in org.apache.tephra.distributed.thrift
 
TTransactionServer.Processor.status() - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.Processor.status
 
TTransactionServer.Processor.truncateInvalidTx<I extends TTransactionServer.Iface> - Class in org.apache.tephra.distributed.thrift
 
TTransactionServer.Processor.truncateInvalidTx() - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.Processor.truncateInvalidTx
 
TTransactionServer.Processor.truncateInvalidTxBefore<I extends TTransactionServer.Iface> - Class in org.apache.tephra.distributed.thrift
 
TTransactionServer.Processor.truncateInvalidTxBefore() - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.Processor.truncateInvalidTxBefore
 
TTransactionServer.resetState_args - Class in org.apache.tephra.distributed.thrift
 
TTransactionServer.resetState_args() - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.resetState_args
 
TTransactionServer.resetState_args(TTransactionServer.resetState_args) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.resetState_args
Performs a deep copy on other.
TTransactionServer.resetState_args._Fields - Enum in org.apache.tephra.distributed.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TTransactionServer.resetState_result - Class in org.apache.tephra.distributed.thrift
 
TTransactionServer.resetState_result() - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.resetState_result
 
TTransactionServer.resetState_result(TTransactionServer.resetState_result) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.resetState_result
Performs a deep copy on other.
TTransactionServer.resetState_result._Fields - Enum in org.apache.tephra.distributed.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TTransactionServer.startLong_args - Class in org.apache.tephra.distributed.thrift
 
TTransactionServer.startLong_args() - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.startLong_args
 
TTransactionServer.startLong_args(TTransactionServer.startLong_args) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.startLong_args
Performs a deep copy on other.
TTransactionServer.startLong_args._Fields - Enum in org.apache.tephra.distributed.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TTransactionServer.startLong_result - Class in org.apache.tephra.distributed.thrift
 
TTransactionServer.startLong_result() - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.startLong_result
 
TTransactionServer.startLong_result(TTransaction) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.startLong_result
 
TTransactionServer.startLong_result(TTransactionServer.startLong_result) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.startLong_result
Performs a deep copy on other.
TTransactionServer.startLong_result._Fields - Enum in org.apache.tephra.distributed.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TTransactionServer.startShort_args - Class in org.apache.tephra.distributed.thrift
 
TTransactionServer.startShort_args() - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.startShort_args
 
TTransactionServer.startShort_args(TTransactionServer.startShort_args) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.startShort_args
Performs a deep copy on other.
TTransactionServer.startShort_args._Fields - Enum in org.apache.tephra.distributed.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TTransactionServer.startShort_result - Class in org.apache.tephra.distributed.thrift
 
TTransactionServer.startShort_result() - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.startShort_result
 
TTransactionServer.startShort_result(TTransaction) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.startShort_result
 
TTransactionServer.startShort_result(TTransactionServer.startShort_result) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.startShort_result
Performs a deep copy on other.
TTransactionServer.startShort_result._Fields - Enum in org.apache.tephra.distributed.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TTransactionServer.startShortTimeout_args - Class in org.apache.tephra.distributed.thrift
 
TTransactionServer.startShortTimeout_args() - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.startShortTimeout_args
 
TTransactionServer.startShortTimeout_args(int) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.startShortTimeout_args
 
TTransactionServer.startShortTimeout_args(TTransactionServer.startShortTimeout_args) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.startShortTimeout_args
Performs a deep copy on other.
TTransactionServer.startShortTimeout_args._Fields - Enum in org.apache.tephra.distributed.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TTransactionServer.startShortTimeout_result - Class in org.apache.tephra.distributed.thrift
 
TTransactionServer.startShortTimeout_result() - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.startShortTimeout_result
 
TTransactionServer.startShortTimeout_result(TTransaction) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.startShortTimeout_result
 
TTransactionServer.startShortTimeout_result(TTransactionServer.startShortTimeout_result) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.startShortTimeout_result
Performs a deep copy on other.
TTransactionServer.startShortTimeout_result._Fields - Enum in org.apache.tephra.distributed.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TTransactionServer.startShortWithTimeout_args - Class in org.apache.tephra.distributed.thrift
 
TTransactionServer.startShortWithTimeout_args() - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_args
 
TTransactionServer.startShortWithTimeout_args(int) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_args
 
TTransactionServer.startShortWithTimeout_args(TTransactionServer.startShortWithTimeout_args) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_args
Performs a deep copy on other.
TTransactionServer.startShortWithTimeout_args._Fields - Enum in org.apache.tephra.distributed.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TTransactionServer.startShortWithTimeout_result - Class in org.apache.tephra.distributed.thrift
 
TTransactionServer.startShortWithTimeout_result() - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_result
 
TTransactionServer.startShortWithTimeout_result(TTransaction, TGenericException) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_result
 
TTransactionServer.startShortWithTimeout_result(TTransactionServer.startShortWithTimeout_result) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_result
Performs a deep copy on other.
TTransactionServer.startShortWithTimeout_result._Fields - Enum in org.apache.tephra.distributed.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TTransactionServer.status_args - Class in org.apache.tephra.distributed.thrift
 
TTransactionServer.status_args() - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.status_args
 
TTransactionServer.status_args(TTransactionServer.status_args) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.status_args
Performs a deep copy on other.
TTransactionServer.status_args._Fields - Enum in org.apache.tephra.distributed.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TTransactionServer.status_result - Class in org.apache.tephra.distributed.thrift
 
TTransactionServer.status_result() - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.status_result
 
TTransactionServer.status_result(String) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.status_result
 
TTransactionServer.status_result(TTransactionServer.status_result) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.status_result
Performs a deep copy on other.
TTransactionServer.status_result._Fields - Enum in org.apache.tephra.distributed.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TTransactionServer.truncateInvalidTx_args - Class in org.apache.tephra.distributed.thrift
 
TTransactionServer.truncateInvalidTx_args() - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTx_args
 
TTransactionServer.truncateInvalidTx_args(Set<Long>) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTx_args
 
TTransactionServer.truncateInvalidTx_args(TTransactionServer.truncateInvalidTx_args) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTx_args
Performs a deep copy on other.
TTransactionServer.truncateInvalidTx_args._Fields - Enum in org.apache.tephra.distributed.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TTransactionServer.truncateInvalidTx_result - Class in org.apache.tephra.distributed.thrift
 
TTransactionServer.truncateInvalidTx_result() - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTx_result
 
TTransactionServer.truncateInvalidTx_result(TBoolean) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTx_result
 
TTransactionServer.truncateInvalidTx_result(TTransactionServer.truncateInvalidTx_result) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTx_result
Performs a deep copy on other.
TTransactionServer.truncateInvalidTx_result._Fields - Enum in org.apache.tephra.distributed.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TTransactionServer.truncateInvalidTxBefore_args - Class in org.apache.tephra.distributed.thrift
 
TTransactionServer.truncateInvalidTxBefore_args() - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_args
 
TTransactionServer.truncateInvalidTxBefore_args(long) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_args
 
TTransactionServer.truncateInvalidTxBefore_args(TTransactionServer.truncateInvalidTxBefore_args) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_args
Performs a deep copy on other.
TTransactionServer.truncateInvalidTxBefore_args._Fields - Enum in org.apache.tephra.distributed.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TTransactionServer.truncateInvalidTxBefore_result - Class in org.apache.tephra.distributed.thrift
 
TTransactionServer.truncateInvalidTxBefore_result() - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_result
 
TTransactionServer.truncateInvalidTxBefore_result(TBoolean, TInvalidTruncateTimeException) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_result
 
TTransactionServer.truncateInvalidTxBefore_result(TTransactionServer.truncateInvalidTxBefore_result) - Constructor for class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_result
Performs a deep copy on other.
TTransactionServer.truncateInvalidTxBefore_result._Fields - Enum in org.apache.tephra.distributed.thrift
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TTransactionType - Enum in org.apache.tephra.distributed.thrift
 
TVisibilityLevel - Enum in org.apache.tephra.distributed.thrift
 
tx - Variable in class org.apache.tephra.AbstractTransactionAwareTable
 
tx - Variable in class org.apache.tephra.distributed.thrift.TTransactionServer.abortTx_args
 
tx - Variable in class org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_args
 
tx - Variable in class org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_args
 
tx - Variable in class org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_args
 
tx - Variable in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidateTx_args
 
TX_OPERATION_ATTRIBUTE_KEY - Static variable in class org.apache.tephra.TxConstants
Key used to set the serialized transaction as an attribute on Get and Scan operations.
TX_ROLLBACK_ATTRIBUTE_KEY - Static variable in class org.apache.tephra.TxConstants
Key used to flag a delete operation as part of a transaction rollback.
txCodec - Variable in class org.apache.tephra.AbstractTransactionAwareTable
 
TxConstants - Class in org.apache.tephra
Transaction system constants
TxConstants() - Constructor for class org.apache.tephra.TxConstants
 
TxConstants.ConflictDetection - Enum in org.apache.tephra
Defines what level of conflict detection should be used for transactions.
TxConstants.HBase - Class in org.apache.tephra
Configuration properties used by HBase
TxConstants.HBase() - Constructor for class org.apache.tephra.TxConstants.HBase
 
TxConstants.Manager - Class in org.apache.tephra
TransactionManager configuration.
TxConstants.Manager() - Constructor for class org.apache.tephra.TxConstants.Manager
 
TxConstants.Metrics - Class in org.apache.tephra
Configuration properties for metrics reporting
TxConstants.Metrics() - Constructor for class org.apache.tephra.TxConstants.Metrics
 
TxConstants.Persist - Class in org.apache.tephra
Configuration for the transaction snapshot persistence.
TxConstants.Persist() - Constructor for class org.apache.tephra.TxConstants.Persist
 
TxConstants.Service - Class in org.apache.tephra
TransactionService configuration.
TxConstants.Service() - Constructor for class org.apache.tephra.TxConstants.Service
 
TxConstants.TransactionLog - Class in org.apache.tephra
Configuration for transaction log edit entries
TxConstants.TransactionLog() - Constructor for class org.apache.tephra.TxConstants.TransactionLog
 
TxConstants.TransactionPruning - Class in org.apache.tephra
Configuration for invalid transaction pruning
TxConstants.TransactionPruning() - Constructor for class org.apache.tephra.TxConstants.TransactionPruning
 
txManager - Variable in class org.apache.tephra.inmemory.InMemoryTransactionService
 
txManagerProvider - Variable in class org.apache.tephra.inmemory.InMemoryTransactionService
 
txMaxLifetimeMillis - Variable in class org.apache.tephra.hbase.coprocessor.TransactionProcessor
 
TxMetricsCollector - Class in org.apache.tephra.metrics
Metrics Collector Class, to emit Transaction Related Metrics.
TxMetricsCollector() - Constructor for class org.apache.tephra.metrics.TxMetricsCollector
 
txnBackwardsCompatCheck(int, long, Map<Long, TransactionManager.InProgressTx>) - Static method in class org.apache.tephra.TransactionManager
Check if in-progress transactions need to be migrated to have expiration time and type, if so do the migration.
txns - Variable in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTx_args
 
TxUtils - Class in org.apache.tephra.util
Utility methods supporting transaction operations.
TxUtils() - Constructor for class org.apache.tephra.util.TxUtils
 
type - Variable in class org.apache.tephra.distributed.thrift.TTransaction
 

U

undoRegister() - Method in class org.apache.tephra.inmemory.InMemoryTransactionService
 
unsetChanges() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_args
 
unsetCheckpointWritePointers() - Method in class org.apache.tephra.distributed.thrift.TTransaction
 
unsetE() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_result
 
unsetE() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_result
 
unsetE() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_result
 
unsetE() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.getSnapshot_result
 
unsetE() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_result
 
unsetE() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_result
 
unsetFirstShort() - Method in class org.apache.tephra.distributed.thrift.TTransaction
 
unsetInProgress() - Method in class org.apache.tephra.distributed.thrift.TTransaction
 
unsetInvalids() - Method in class org.apache.tephra.distributed.thrift.TTransaction
 
unsetMessage() - Method in exception org.apache.tephra.distributed.thrift.TGenericException
 
unsetMessage() - Method in exception org.apache.tephra.distributed.thrift.TInvalidTruncateTimeException
 
unsetMessage() - Method in exception org.apache.tephra.distributed.thrift.TTransactionCouldNotTakeSnapshotException
 
unsetMessage() - Method in exception org.apache.tephra.distributed.thrift.TTransactionNotInProgressException
 
unsetOriginalExceptionClass() - Method in exception org.apache.tephra.distributed.thrift.TGenericException
 
unsetReadPointer() - Method in class org.apache.tephra.distributed.thrift.TTransaction
 
unsetSuccess() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_result
 
unsetSuccess() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_result
 
unsetSuccess() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_result
 
unsetSuccess() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.getSnapshot_result
 
unsetSuccess() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidateTx_result
 
unsetSuccess() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidTxSize_result
 
unsetSuccess() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startLong_result
 
unsetSuccess() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShort_result
 
unsetSuccess() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortTimeout_result
 
unsetSuccess() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_result
 
unsetSuccess() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.status_result
 
unsetSuccess() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTx_result
 
unsetSuccess() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_result
 
unsetTime() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_args
 
unsetTimeout() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortTimeout_args
 
unsetTimeout() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_args
 
unsetTransactionId() - Method in class org.apache.tephra.distributed.thrift.TTransaction
 
unsetTx() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.abortTx_args
 
unsetTx() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_args
 
unsetTx() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_args
 
unsetTx() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_args
 
unsetTx() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidateTx_args
 
unsetTxns() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTx_args
 
unsetType() - Method in class org.apache.tephra.distributed.thrift.TTransaction
 
unsetValue() - Method in class org.apache.tephra.distributed.thrift.TBoolean
 
unsetVisibilityLevel() - Method in class org.apache.tephra.distributed.thrift.TTransaction
 
unsetWritePointer() - Method in class org.apache.tephra.distributed.thrift.TTransaction
 
unwrap(TTransaction) - Static method in class org.apache.tephra.distributed.TransactionConverterUtils
 
updateTx(Transaction) - Method in class org.apache.tephra.AbstractTransactionAwareTable
 
updateTx(Transaction) - Method in interface org.apache.tephra.TransactionAware
Called when the state of the current transaction has been updated.

V

validate() - Method in class org.apache.tephra.distributed.thrift.TBoolean
 
validate() - Method in exception org.apache.tephra.distributed.thrift.TGenericException
 
validate() - Method in exception org.apache.tephra.distributed.thrift.TInvalidTruncateTimeException
 
validate() - Method in class org.apache.tephra.distributed.thrift.TTransaction
 
validate() - Method in exception org.apache.tephra.distributed.thrift.TTransactionCouldNotTakeSnapshotException
 
validate() - Method in exception org.apache.tephra.distributed.thrift.TTransactionNotInProgressException
 
validate() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.abortTx_args
 
validate() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.abortTx_result
 
validate() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_args
 
validate() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_result
 
validate() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_args
 
validate() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_result
 
validate() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_args
 
validate() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_result
 
validate() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.getSnapshot_args
 
validate() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.getSnapshot_result
 
validate() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidateTx_args
 
validate() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidateTx_result
 
validate() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidTxSize_args
 
validate() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidTxSize_result
 
validate() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.resetState_args
 
validate() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.resetState_result
 
validate() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startLong_args
 
validate() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startLong_result
 
validate() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShort_args
 
validate() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShort_result
 
validate() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortTimeout_args
 
validate() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortTimeout_result
 
validate() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_args
 
validate() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_result
 
validate() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.status_args
 
validate() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.status_result
 
validate() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTx_args
 
validate() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTx_result
 
validate() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_args
 
validate() - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_result
 
validate() - Method in class org.apache.thrift.server.TThreadedSelectorServerWithFix.Args
 
value - Variable in class org.apache.tephra.distributed.thrift.TBoolean
 
valueOf(String) - Static method in enum co.cask.tephra.persist.TransactionEdit.State
Deprecated.
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.tephra.distributed.thrift.TBoolean._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.tephra.distributed.thrift.TGenericException._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.tephra.distributed.thrift.TInvalidTruncateTimeException._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransaction._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionCouldNotTakeSnapshotException._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionNotInProgressException._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.abortTx_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.abortTx_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.getSnapshot_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.getSnapshot_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.invalidateTx_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.invalidateTx_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.invalidTxSize_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.invalidTxSize_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.resetState_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.resetState_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.startLong_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.startLong_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.startShort_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.startShort_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.startShortTimeout_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.startShortTimeout_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.status_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.status_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTx_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTx_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.tephra.distributed.thrift.TTransactionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.tephra.distributed.thrift.TVisibilityLevel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.tephra.persist.TransactionEdit.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.tephra.Transaction.VisibilityLevel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.tephra.TransactionManager.InProgressType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.tephra.TransactionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.tephra.TxConstants.ConflictDetection
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.tephra.util.HBaseVersion.Version
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.thrift.server.TThreadedSelectorServerWithFix.Args.AcceptPolicy
Returns the enum constant of this type with the specified name.
values() - Static method in enum co.cask.tephra.persist.TransactionEdit.State
Deprecated.
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.tephra.distributed.thrift.TBoolean._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.tephra.distributed.thrift.TGenericException._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.tephra.distributed.thrift.TInvalidTruncateTimeException._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.tephra.distributed.thrift.TTransaction._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.tephra.distributed.thrift.TTransactionCouldNotTakeSnapshotException._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.tephra.distributed.thrift.TTransactionNotInProgressException._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.abortTx_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.abortTx_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.getSnapshot_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.getSnapshot_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.invalidateTx_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.invalidateTx_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.invalidTxSize_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.invalidTxSize_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.resetState_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.resetState_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.startLong_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.startLong_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.startShort_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.startShort_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.startShortTimeout_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.startShortTimeout_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.status_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.status_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTx_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTx_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.tephra.distributed.thrift.TTransactionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.tephra.distributed.thrift.TVisibilityLevel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.tephra.persist.TransactionEdit.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.tephra.Transaction.VisibilityLevel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.tephra.TransactionManager.InProgressType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.tephra.TransactionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.tephra.TxConstants.ConflictDetection
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.tephra.util.HBaseVersion.Version
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.thrift.server.TThreadedSelectorServerWithFix.Args.AcceptPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
verify() - Method in class org.apache.tephra.examples.BalanceBooks
Validates the current state of the data stored at the end of the test.
VERSION_KEY - Static variable in class org.apache.tephra.TxConstants.TransactionLog
 
VisibilityFence - Class in org.apache.tephra.visibility
VisibilityFence is used to ensure that after a given point in time, all readers see an updated change that got committed.
visibilityLevel - Variable in class org.apache.tephra.distributed.thrift.TTransaction
 

W

waitForShutdown() - Method in class org.apache.thrift.server.TThreadedSelectorServerWithFix
Joins the accept and selector threads and shuts down the executor service.
wakeupSelector() - Method in class org.apache.thrift.server.TThreadedSelectorServerWithFix.AcceptThread
If the selector is blocked, wake it up.
workerThreads(int) - Method in class org.apache.thrift.server.TThreadedSelectorServerWithFix.Args
 
wrap(Transaction) - Static method in class org.apache.tephra.distributed.TransactionConverterUtils
 
write(DataOutput) - Method in class co.cask.tephra.persist.TransactionEdit
Deprecated.
 
write(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TBoolean
 
write(TProtocol) - Method in exception org.apache.tephra.distributed.thrift.TGenericException
 
write(TProtocol) - Method in exception org.apache.tephra.distributed.thrift.TInvalidTruncateTimeException
 
write(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransaction
 
write(TProtocol) - Method in exception org.apache.tephra.distributed.thrift.TTransactionCouldNotTakeSnapshotException
 
write(TProtocol) - Method in exception org.apache.tephra.distributed.thrift.TTransactionNotInProgressException
 
write(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.abortTx_args
 
write(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.abortTx_result
 
write(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_args
 
write(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.canCommitTx_result
 
write(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_args
 
write(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.checkpoint_result
 
write(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_args
 
write(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.commitTx_result
 
write(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.getSnapshot_args
 
write(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.getSnapshot_result
 
write(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidateTx_args
 
write(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidateTx_result
 
write(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidTxSize_args
 
write(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.invalidTxSize_result
 
write(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.resetState_args
 
write(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.resetState_result
 
write(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startLong_args
 
write(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startLong_result
 
write(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShort_args
 
write(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShort_result
 
write(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortTimeout_args
 
write(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortTimeout_result
 
write(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_args
 
write(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.startShortWithTimeout_result
 
write(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.status_args
 
write(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.status_result
 
write(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTx_args
 
write(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTx_result
 
write(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_args
 
write(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.truncateInvalidTxBefore_result
 
write(DataOutput) - Method in class org.apache.tephra.persist.AbstractTransactionLog.Entry
 
write(DataOutput) - Method in class org.apache.tephra.persist.TransactionEdit
 
write_args(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.AsyncClient.abortTx_call
 
write_args(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.AsyncClient.canCommitTx_call
 
write_args(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.AsyncClient.checkpoint_call
 
write_args(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.AsyncClient.commitTx_call
 
write_args(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.AsyncClient.getSnapshot_call
 
write_args(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.AsyncClient.invalidateTx_call
 
write_args(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.AsyncClient.invalidTxSize_call
 
write_args(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.AsyncClient.resetState_call
 
write_args(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.AsyncClient.startLong_call
 
write_args(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.AsyncClient.startShort_call
 
write_args(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.AsyncClient.startShortTimeout_call
 
write_args(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.AsyncClient.startShortWithTimeout_call
 
write_args(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.AsyncClient.status_call
 
write_args(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.AsyncClient.truncateInvalidTx_call
 
write_args(TProtocol) - Method in class org.apache.tephra.distributed.thrift.TTransactionServer.AsyncClient.truncateInvalidTxBefore_call
 
writeBytes(byte[]) - Method in class org.apache.tephra.snapshot.BinaryEncoder
write a sequence of bytes.
writeInt(int) - Method in class org.apache.tephra.snapshot.BinaryEncoder
write a single int value.
writeLong(long) - Method in class org.apache.tephra.snapshot.BinaryEncoder
write a single long int value.
writeMarker(SequenceFile.Writer, int) - Static method in class org.apache.tephra.persist.CommitMarkerCodec
 
writePointer - Variable in class org.apache.tephra.distributed.thrift.TTransaction
 
writeSnapshot(OutputStream, TransactionSnapshot) - Method in class org.apache.tephra.persist.AbstractTransactionStateStorage
 
writeSnapshot(TransactionSnapshot) - Method in class org.apache.tephra.persist.HDFSTransactionStateStorage
 
writeSnapshot(TransactionSnapshot) - Method in class org.apache.tephra.persist.LocalFileTransactionStateStorage
 
writeSnapshot(OutputStream, TransactionSnapshot) - Method in class org.apache.tephra.persist.NoOpTransactionStateStorage
 
writeSnapshot(TransactionSnapshot) - Method in class org.apache.tephra.persist.NoOpTransactionStateStorage
 
writeSnapshot(OutputStream, TransactionSnapshot) - Method in interface org.apache.tephra.persist.TransactionStateStorage
Persists a snapshot of transaction state to an output stream.
writeSnapshot(TransactionSnapshot) - Method in interface org.apache.tephra.persist.TransactionStateStorage
Persists a snapshot of transaction state.

Z

ZK_SESSION_TIMEOUT - Static variable in class org.apache.tephra.TxConstants.HBase
 
ZKModule - Class in org.apache.tephra.runtime
Provides Guice binding to ZKClient and ZKClientService.
ZKModule() - Constructor for class org.apache.tephra.runtime.ZKModule
 
ZOOKEEPER_QUORUM - Static variable in class org.apache.tephra.TxConstants.HBase
 
A B C D E F G H I J L M N O P R S T U V W Z 

Copyright © 2017 The Apache Software Foundation. All rights reserved.