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

A

ALWAYS_FIRST_POSITION - Static variable in class bitronix.tm.utils.Scheduler
 
ALWAYS_FIRST_POSITION_KEY - Static variable in class bitronix.tm.utils.Scheduler
 
ALWAYS_LAST_POSITION - Static variable in class bitronix.tm.utils.Scheduler
 
ALWAYS_LAST_POSITION_KEY - Static variable in class bitronix.tm.utils.Scheduler
 
AbstractPhaseEngine - class bitronix.tm.twopc.AbstractPhaseEngine.
Abstract phase execution engine.
AbstractPhaseEngine(Executor) - Constructor for class bitronix.tm.twopc.AbstractPhaseEngine
 
AbstractXAResourceHolder - class bitronix.tm.resource.common.AbstractXAResourceHolder.
Implementation of all services required by a XAResourceHolder.
AbstractXAResourceHolder() - Constructor for class bitronix.tm.resource.common.AbstractXAResourceHolder
 
AbstractXAStatefulHolder - class bitronix.tm.resource.common.AbstractXAStatefulHolder.
Implementation of all services required by a XAStatefulHolder.
AbstractXAStatefulHolder() - Constructor for class bitronix.tm.resource.common.AbstractXAStatefulHolder
 
acceptLog(TransactionLogRecord) - Method in class bitronix.tm.gui.PendingTransactionTableModel
 
acceptLog(TransactionLogRecord) - Method in class bitronix.tm.gui.RawTransactionTableModel
 
acceptLog(TransactionLogRecord) - Method in class bitronix.tm.gui.TransactionTableModel
 
add(Object, int) - Method in class bitronix.tm.utils.Scheduler
 
addConnectionEventListener(ConnectionEventListener) - Method in class bitronix.tm.resource.jdbc.lrc.LrcXAConnection
 
addEvictionListener(LruEvictionListener) - Method in class bitronix.tm.resource.jdbc.LruStatementCache
 
addStateChangeEventListener(StateChangeListener) - Method in class bitronix.tm.resource.common.AbstractXAStatefulHolder
 
addStateChangeEventListener(StateChangeListener) - Method in interface bitronix.tm.resource.common.XAStatefulHolder
Register an implementation of StateChangeListener.
addTableModelListener(TableModelListener) - Method in class bitronix.tm.gui.PendingTransactionTableModel
 
addTableModelListener(TableModelListener) - Method in class bitronix.tm.gui.RawTransactionTableModel
 
addToEnvironment(String, Object) - Method in class bitronix.tm.jndi.BitronixContext
 
addTransactionStatusChangeListener(TransactionStatusChangeListener) - Method in class bitronix.tm.BitronixTransaction
 
addTreeModelListener(TreeModelListener) - Method in class bitronix.tm.gui.ResourcesTreeModel
 
afterCompletion(int) - Method in class bitronix.tm.resource.common.DeferredReleaseSynchronization
 

B

BackportConcurrentExecutor - class bitronix.tm.twopc.executor.BackportConcurrentExecutor.
Abstraction of the java.util.concurrent backport implementation.
BackportConcurrentExecutor() - Constructor for class bitronix.tm.twopc.executor.BackportConcurrentExecutor
 
BaseProxyHandlerClass - class bitronix.tm.resource.jdbc.BaseProxyHandlerClass.
Base class for Proxy InvocationHandlers.
BaseProxyHandlerClass() - Constructor for class bitronix.tm.resource.jdbc.BaseProxyHandlerClass
 
BitronixContext - class bitronix.tm.jndi.BitronixContext.
Implementation of Context that allows lookup of transaction manager and registered resources.
BitronixContext() - Constructor for class bitronix.tm.jndi.BitronixContext
 
BitronixHeuristicCommitException - exception bitronix.tm.internal.BitronixHeuristicCommitException.
Subclass of HeuristicCommitException supporting nested Throwables.
BitronixHeuristicCommitException(String) - Constructor for class bitronix.tm.internal.BitronixHeuristicCommitException
 
BitronixHeuristicCommitException(String, Throwable) - Constructor for class bitronix.tm.internal.BitronixHeuristicCommitException
 
BitronixHeuristicMixedException - exception bitronix.tm.internal.BitronixHeuristicMixedException.
Subclass of HeuristicMixedException supporting nested Throwables.
BitronixHeuristicMixedException(String) - Constructor for class bitronix.tm.internal.BitronixHeuristicMixedException
 
BitronixHeuristicMixedException(String, Throwable) - Constructor for class bitronix.tm.internal.BitronixHeuristicMixedException
 
BitronixHeuristicRollbackException - exception bitronix.tm.internal.BitronixHeuristicRollbackException.
Subclass of HeuristicRollbackException supporting nested Throwables.
BitronixHeuristicRollbackException(String) - Constructor for class bitronix.tm.internal.BitronixHeuristicRollbackException
 
BitronixHeuristicRollbackException(String, Throwable) - Constructor for class bitronix.tm.internal.BitronixHeuristicRollbackException
 
BitronixInitialContextFactory - class bitronix.tm.jndi.BitronixInitialContextFactory.
Implementation of InitialContextFactory that allows lookup of transaction manager and registered resources.
BitronixInitialContextFactory() - Constructor for class bitronix.tm.jndi.BitronixInitialContextFactory
 
BitronixMultiSystemException - exception bitronix.tm.internal.BitronixMultiSystemException.
Subclass of SystemException supporting nested Throwables.
BitronixMultiSystemException(String, List, List) - Constructor for class bitronix.tm.internal.BitronixMultiSystemException
 
BitronixRollbackException - exception bitronix.tm.internal.BitronixRollbackException.
Subclass of RollbackException supporting nested Throwables.
BitronixRollbackException(String) - Constructor for class bitronix.tm.internal.BitronixRollbackException
 
BitronixRollbackException(String, Throwable) - Constructor for class bitronix.tm.internal.BitronixRollbackException
 
BitronixRollbackSystemException - exception bitronix.tm.internal.BitronixRollbackSystemException.
Subclass of SystemException indicating a rollback must be performed.
BitronixRollbackSystemException(String, Throwable) - Constructor for class bitronix.tm.internal.BitronixRollbackSystemException
 
BitronixRuntimeException - exception bitronix.tm.internal.BitronixRuntimeException.
Thrown when a runtime exception happens.
BitronixRuntimeException(String, Throwable) - Constructor for class bitronix.tm.internal.BitronixRuntimeException
 
BitronixRuntimeException(String) - Constructor for class bitronix.tm.internal.BitronixRuntimeException
 
BitronixSystemException - exception bitronix.tm.internal.BitronixSystemException.
Subclass of SystemException supporting nested Throwables.
BitronixSystemException(int) - Constructor for class bitronix.tm.internal.BitronixSystemException
 
BitronixSystemException(String) - Constructor for class bitronix.tm.internal.BitronixSystemException
 
BitronixSystemException(String, Throwable) - Constructor for class bitronix.tm.internal.BitronixSystemException
 
BitronixTransaction - class bitronix.tm.BitronixTransaction.
Implementation of Transaction.
BitronixTransaction() - Constructor for class bitronix.tm.BitronixTransaction
 
BitronixTransactionMBean - interface bitronix.tm.BitronixTransactionMBean.
BitronixTransaction Management interface.
BitronixTransactionManager - class bitronix.tm.BitronixTransactionManager.
Implementation of TransactionManager and UserTransaction.
BitronixTransactionManager() - Constructor for class bitronix.tm.BitronixTransactionManager
Create the BitronixTransactionManager.
BitronixTransactionManagerObjectFactory - class bitronix.tm.BitronixTransactionManagerObjectFactory.
BitronixTransactionManager object factory for JNDI references.
BitronixTransactionManagerObjectFactory() - Constructor for class bitronix.tm.BitronixTransactionManagerObjectFactory
 
BitronixTransactionSynchronizationRegistry - class bitronix.tm.BitronixTransactionSynchronizationRegistry.
Implementation of JTA 1.1 TransactionSynchronizationRegistry.
BitronixTransactionSynchronizationRegistry() - Constructor for class bitronix.tm.BitronixTransactionSynchronizationRegistry
 
BitronixTransactionSynchronizationRegistryObjectFactory - class bitronix.tm.BitronixTransactionSynchronizationRegistryObjectFactory.
BitronixTransactionSynchronizationRegistry object factory for JNDI references.
BitronixTransactionSynchronizationRegistryObjectFactory() - Constructor for class bitronix.tm.BitronixTransactionSynchronizationRegistryObjectFactory
 
BitronixUserTransactionObjectFactory - class bitronix.tm.BitronixUserTransactionObjectFactory.
BitronixTransactionManager object factory for JNDI references.
BitronixUserTransactionObjectFactory() - Constructor for class bitronix.tm.BitronixUserTransactionObjectFactory
 
BitronixXAException - exception bitronix.tm.internal.BitronixXAException.
Subclass of XAException supporting nested Throwables.
BitronixXAException(String, int) - Constructor for class bitronix.tm.internal.BitronixXAException
 
BitronixXAException(String, int, Throwable) - Constructor for class bitronix.tm.internal.BitronixXAException
 
BitronixXid - class bitronix.tm.BitronixXid.
Implementation of Xid.
BitronixXid(Uid, Uid) - Constructor for class bitronix.tm.BitronixXid
Create a new XID using the specified GTRID and BQUAL.
BitronixXid(Xid) - Constructor for class bitronix.tm.BitronixXid
 
beforeCompletion() - Method in class bitronix.tm.resource.common.DeferredReleaseSynchronization
 
begin() - Method in class bitronix.tm.BitronixTransactionManager
Start a new transaction and bind the context to the calling thread.
bind(Name, Object) - Method in class bitronix.tm.jndi.BitronixContext
 
bind(String, Object) - Method in class bitronix.tm.jndi.BitronixContext
 
bitronix.tm - package bitronix.tm
JTA interfaces implementations and global services.
bitronix.tm.gui - package bitronix.tm.gui
GUI admin console.
bitronix.tm.internal - package bitronix.tm.internal
Internal implementation details.
bitronix.tm.jndi - package bitronix.tm.jndi
JNDI provider implementation that allows looking up transaction manager and resources.
bitronix.tm.journal - package bitronix.tm.journal
Transactions disk journal.
bitronix.tm.recovery - package bitronix.tm.recovery
Recovery logic.
bitronix.tm.resource - package bitronix.tm.resource
Transaction Manager's resource management services.
bitronix.tm.resource.common - package bitronix.tm.resource.common
Resource management code common across all resource types.
bitronix.tm.resource.ehcache - package bitronix.tm.resource.ehcache
Ehcache specific resource management code.
bitronix.tm.resource.jdbc - package bitronix.tm.resource.jdbc
JDBC specific resource management code.
bitronix.tm.resource.jdbc.lrc - package bitronix.tm.resource.jdbc.lrc
XADataSource emulator using Last Resource Commit on an underlying non-XA DataSource.
bitronix.tm.resource.jms - package bitronix.tm.resource.jms
Synchronous JMS specific resource management code.
bitronix.tm.resource.jms.lrc - package bitronix.tm.resource.jms.lrc
XAConnectionFactory emulator using Last Resource Commit on an underlying non-XA ConnectionFactory.
bitronix.tm.timer - package bitronix.tm.timer
Timed tasks scheduler.
bitronix.tm.twopc - package bitronix.tm.twopc
Two-phase commit logic.
bitronix.tm.twopc.executor - package bitronix.tm.twopc.executor
Two-phase commit commands executors.
bitronix.tm.utils - package bitronix.tm.utils
Misc utility classes.
buildServerIdArray() - Method in class bitronix.tm.Configuration
Build the server ID byte array that will be prepended in generated UIDs.
bytesToInt(byte[], int) - Static method in class bitronix.tm.utils.Encoder
 
bytesToLong(byte[], int) - Static method in class bitronix.tm.utils.Encoder
 

C

CLEAN_LOG_STATE - Static variable in class bitronix.tm.journal.TransactionLogHeader
State of the log file when it has been closed properly.
CURRENT_POSITION_HEADER - Static variable in class bitronix.tm.journal.TransactionLogHeader
Position of the current log position in the header.
ClassLoaderUtils - class bitronix.tm.utils.ClassLoaderUtils.
Static utility methods for loading classes and resources.
ClassLoaderUtils() - Constructor for class bitronix.tm.utils.ClassLoaderUtils
 
CollectionUtils - class bitronix.tm.utils.CollectionUtils.
Collection helper functions.
CollectionUtils() - Constructor for class bitronix.tm.utils.CollectionUtils
 
Committer - class bitronix.tm.twopc.Committer.
Phase 2 Commit logic engine.
Committer(Executor) - Constructor for class bitronix.tm.twopc.Committer
 
ConcurrentExecutor - class bitronix.tm.twopc.executor.ConcurrentExecutor.
Abstraction of the java.util.concurrent JDK 1.5+ implementation.
ConcurrentExecutor() - Constructor for class bitronix.tm.twopc.executor.ConcurrentExecutor
 
ConcurrentExecutor(String[]) - Constructor for class bitronix.tm.twopc.executor.ConcurrentExecutor
 
Configuration - class bitronix.tm.Configuration.
Configuration repository of the transaction manager.
Configuration() - Constructor for class bitronix.tm.Configuration
 
Console - class bitronix.tm.gui.Console.
© Bitronix Software
Console() - Constructor for class bitronix.tm.gui.Console
 
CorruptedTransactionLogException - exception bitronix.tm.journal.CorruptedTransactionLogException.
Thrown by TransactionLogCursor when an integrity check fails upon reading a record.
CorruptedTransactionLogException(String) - Constructor for class bitronix.tm.journal.CorruptedTransactionLogException
 
CryptoEngine - class bitronix.tm.utils.CryptoEngine.
Simple crypto helper that uses symetric keys to crypt and decrypt resources passwords.
CryptoEngine() - Constructor for class bitronix.tm.utils.CryptoEngine
 
calculateCrc32() - Method in class bitronix.tm.journal.TransactionLogRecord
Calculate the CRC32 value of this record.
cancelPoolShrinking(XAPool) - Method in class bitronix.tm.timer.TaskScheduler
Cancel the task that will tell a XA pool to close idle connections.
cancelRecovery(Recoverer) - Method in class bitronix.tm.timer.TaskScheduler
Cancel the task that will run background recovery at the specified date.
cancelTransactionTimeout(BitronixTransaction) - Method in class bitronix.tm.timer.TaskScheduler
Cancel the task that will mark the transaction as timed out at the specified date.
clear() - Static method in class bitronix.tm.TransactionManagerServices
Clear services references.
clear() - Method in class bitronix.tm.journal.DiskForceWaitQueue
 
clear() - Method in class bitronix.tm.resource.jdbc.LruStatementCache
Evict all statements from the cache.
clearXAResourceHolderStates() - Method in class bitronix.tm.internal.XAResourceManager
Remove this transaction's XAResourceHolderState from all enlisted XAResourceHolders.
close() - Method in class bitronix.tm.jndi.BitronixContext
 
close() - Method in class bitronix.tm.journal.DiskJournal
Close the disk journal and the underlying files.
close() - Method in interface bitronix.tm.journal.Journal
Close this journal and release all underlying resources.
close() - Method in class bitronix.tm.journal.NullJournal
 
close() - Method in class bitronix.tm.journal.TransactionLogAppender
Close the appender and the underlying file.
close() - Method in class bitronix.tm.journal.TransactionLogCursor
Close the cursor and the underlying file
close() - Method in class bitronix.tm.resource.common.RecoveryXAResourceHolder
 
close() - Method in class bitronix.tm.resource.common.XAPool
 
close() - Method in interface bitronix.tm.resource.common.XAResourceProducer
Release this XAResourceProducer's internal resources.
close() - Method in interface bitronix.tm.resource.common.XAStatefulHolder
Close the physical connection that this XAStatefulHolder represents.
close() - Method in class bitronix.tm.resource.ehcache.EhCacheXAResourceHolder
Close the physical connection that this XAStatefulHolder represents.
close() - Method in class bitronix.tm.resource.ehcache.EhCacheXAResourceProducer
Release this XAResourceProducer's internal resources.
close() - Method in class bitronix.tm.resource.jdbc.JdbcCallableStatementHandle
 
close() - Method in class bitronix.tm.resource.jdbc.JdbcConnectionHandle
 
close() - Method in class bitronix.tm.resource.jdbc.JdbcPooledConnection
 
close() - Method in class bitronix.tm.resource.jdbc.JdbcPreparedStatementHandle
 
close() - Method in class bitronix.tm.resource.jdbc.JdbcStatementHandle
 
close() - Method in class bitronix.tm.resource.jdbc.JdbcUncachedPreparedStatementHandle
 
close() - Method in class bitronix.tm.resource.jdbc.PoolingDataSource
 
close() - Method in class bitronix.tm.resource.jdbc.lrc.LrcConnectionHandle
 
close() - Method in class bitronix.tm.resource.jdbc.lrc.LrcXAConnection
 
close() - Method in class bitronix.tm.resource.jms.DualSessionWrapper
 
close() - Method in class bitronix.tm.resource.jms.JmsConnectionHandle
 
close() - Method in class bitronix.tm.resource.jms.JmsPooledConnection
 
close() - Method in class bitronix.tm.resource.jms.MessageConsumerWrapper
 
close() - Method in class bitronix.tm.resource.jms.MessageProducerWrapper
 
close() - Method in class bitronix.tm.resource.jms.PoolingConnectionFactory
 
close() - Method in class bitronix.tm.resource.jms.lrc.LrcXAConnection
 
close() - Method in class bitronix.tm.resource.jms.lrc.LrcXASession
 
collectDanglingRecords() - Method in class bitronix.tm.journal.DiskJournal
Collect all dangling records of the active log file.
collectDanglingRecords() - Method in interface bitronix.tm.journal.Journal
Collect all dangling records of the journal, ie: COMMITTING records with no corresponding COMMITTED record.
collectDanglingRecords() - Method in class bitronix.tm.journal.NullJournal
 
collectNotInterestedResources(List, List) - Static method in class bitronix.tm.twopc.AbstractPhaseEngine
 
collectResourcesNames(Collection) - Static method in class bitronix.tm.utils.Decoder
Create a String representation of a list of XAResourceHolders.
collectResourcesUniqueNames(List) - Static method in class bitronix.tm.twopc.AbstractPhaseEngine
 
collectUniqueNames() - Method in class bitronix.tm.internal.XAResourceManager
Get a Set of unique names of all the enlisted XAResourceHolderStates.
commit() - Method in class bitronix.tm.BitronixTransaction
 
commit() - Method in class bitronix.tm.BitronixTransactionManager
 
commit(XAResourceHolderState, Xid) - Static method in class bitronix.tm.recovery.RecoveryHelper
Commit the specified branch of a dangling transaction.
commit() - Method in class bitronix.tm.resource.jdbc.JdbcConnectionHandle
 
commit() - Method in class bitronix.tm.resource.jdbc.lrc.LrcConnectionHandle
 
commit(Xid, boolean) - Method in class bitronix.tm.resource.jdbc.lrc.LrcXAResource
 
commit() - Method in class bitronix.tm.resource.jms.DualSessionWrapper
 
commit(Xid, boolean) - Method in class bitronix.tm.resource.jms.lrc.LrcXAResource
 
commit() - Method in class bitronix.tm.resource.jms.lrc.LrcXASession
 
commit(BitronixTransaction, List) - Method in class bitronix.tm.twopc.Committer
Execute phase 2 commit.
composeName(Name, Name) - Method in class bitronix.tm.jndi.BitronixContext
 
composeName(String, String) - Method in class bitronix.tm.jndi.BitronixContext
 
containsByIdentity(Collection, Object) - Static method in class bitronix.tm.utils.CollectionUtils
Check if a collection contains a specific object by searching for it by identity instead of by using equals/hashcode.
countTasksQueued() - Method in class bitronix.tm.timer.TaskScheduler
Get the amount of tasks currently queued.
createBrowser(Queue) - Method in class bitronix.tm.resource.jms.DualSessionWrapper
 
createBrowser(Queue, String) - Method in class bitronix.tm.resource.jms.DualSessionWrapper
 
createBrowser(Queue) - Method in class bitronix.tm.resource.jms.lrc.LrcXASession
 
createBrowser(Queue, String) - Method in class bitronix.tm.resource.jms.lrc.LrcXASession
 
createBytesMessage() - Method in class bitronix.tm.resource.jms.DualSessionWrapper
 
createBytesMessage() - Method in class bitronix.tm.resource.jms.lrc.LrcXASession
 
createConnection() - Method in class bitronix.tm.resource.jms.PoolingConnectionFactory
 
createConnection(String, String) - Method in class bitronix.tm.resource.jms.PoolingConnectionFactory
 
createConnectionConsumer(Destination, String, ServerSessionPool, int) - Method in class bitronix.tm.resource.jms.JmsConnectionHandle
 
createConnectionConsumer(Destination, String, ServerSessionPool, int) - Method in class bitronix.tm.resource.jms.lrc.LrcXAConnection
 
createConsumer(Destination) - Method in class bitronix.tm.resource.jms.DualSessionWrapper
 
createConsumer(Destination, String) - Method in class bitronix.tm.resource.jms.DualSessionWrapper
 
createConsumer(Destination, String, boolean) - Method in class bitronix.tm.resource.jms.DualSessionWrapper
 
createConsumer(Destination) - Method in class bitronix.tm.resource.jms.lrc.LrcXASession
 
createConsumer(Destination, String) - Method in class bitronix.tm.resource.jms.lrc.LrcXASession
 
createConsumer(Destination, String, boolean) - Method in class bitronix.tm.resource.jms.lrc.LrcXASession
 
createDurableConnectionConsumer(Topic, String, String, ServerSessionPool, int) - Method in class bitronix.tm.resource.jms.JmsConnectionHandle
 
createDurableConnectionConsumer(Topic, String, String, ServerSessionPool, int) - Method in class bitronix.tm.resource.jms.lrc.LrcXAConnection
 
createDurableSubscriber(Topic, String) - Method in class bitronix.tm.resource.jms.DualSessionWrapper
 
createDurableSubscriber(Topic, String, String, boolean) - Method in class bitronix.tm.resource.jms.DualSessionWrapper
 
createDurableSubscriber(Topic, String) - Method in class bitronix.tm.resource.jms.lrc.LrcXASession
 
createDurableSubscriber(Topic, String, String, boolean) - Method in class bitronix.tm.resource.jms.lrc.LrcXASession
 
createJob(XAResourceHolderState) - Method in class bitronix.tm.twopc.AbstractPhaseEngine
Create a Job that is going to execute the phase command on the given resource.
createJob(XAResourceHolderState) - Method in class bitronix.tm.twopc.Committer
 
createJob(XAResourceHolderState) - Method in class bitronix.tm.twopc.Preparer
 
createJob(XAResourceHolderState) - Method in class bitronix.tm.twopc.Rollbacker
 
createMapMessage() - Method in class bitronix.tm.resource.jms.DualSessionWrapper
 
createMapMessage() - Method in class bitronix.tm.resource.jms.lrc.LrcXASession
 
createMessage() - Method in class bitronix.tm.resource.jms.DualSessionWrapper
 
createMessage() - Method in class bitronix.tm.resource.jms.lrc.LrcXASession
 
createObjectMessage() - Method in class bitronix.tm.resource.jms.DualSessionWrapper
 
createObjectMessage(Serializable) - Method in class bitronix.tm.resource.jms.DualSessionWrapper
 
createObjectMessage() - Method in class bitronix.tm.resource.jms.lrc.LrcXASession
 
createObjectMessage(Serializable) - Method in class bitronix.tm.resource.jms.lrc.LrcXASession
 
createPooledConnection(Object, ResourceBean) - Method in interface bitronix.tm.resource.common.XAResourceProducer
Create a XAStatefulHolder that will be placed in an XAPool.
createPooledConnection(Object, ResourceBean) - Method in class bitronix.tm.resource.ehcache.EhCacheXAResourceProducer
Create a XAStatefulHolder that will be placed in an XAPool.
createPooledConnection(Object, ResourceBean) - Method in class bitronix.tm.resource.jdbc.PoolingDataSource
 
createPooledConnection(Object, ResourceBean) - Method in class bitronix.tm.resource.jms.PoolingConnectionFactory
 
createProducer(Destination) - Method in class bitronix.tm.resource.jms.DualSessionWrapper
 
createProducer(Destination) - Method in class bitronix.tm.resource.jms.lrc.LrcXASession
 
createQueue(String) - Method in class bitronix.tm.resource.jms.DualSessionWrapper
 
createQueue(String) - Method in class bitronix.tm.resource.jms.lrc.LrcXASession
 
createRecoveryXAResourceHolder() - Method in class bitronix.tm.resource.jdbc.JdbcPooledConnection
 
createRecoveryXAResourceHolder() - Method in class bitronix.tm.resource.jms.JmsPooledConnection
 
createSession(boolean, int) - Method in class bitronix.tm.resource.jms.JmsConnectionHandle
 
createSession(boolean, int) - Method in class bitronix.tm.resource.jms.JmsPooledConnection
 
createSession(boolean, int) - Method in class bitronix.tm.resource.jms.lrc.LrcXAConnection
 
createStatement() - Method in class bitronix.tm.resource.jdbc.JdbcConnectionHandle
 
createStatement(int, int) - Method in class bitronix.tm.resource.jdbc.JdbcConnectionHandle
 
createStatement(int, int, int) - Method in class bitronix.tm.resource.jdbc.JdbcConnectionHandle
 
createStreamMessage() - Method in class bitronix.tm.resource.jms.DualSessionWrapper
 
createStreamMessage() - Method in class bitronix.tm.resource.jms.lrc.LrcXASession
 
createSubcontext(Name) - Method in class bitronix.tm.jndi.BitronixContext
 
createSubcontext(String) - Method in class bitronix.tm.jndi.BitronixContext
 
createTemporaryQueue() - Method in class bitronix.tm.resource.jms.DualSessionWrapper
 
createTemporaryQueue() - Method in class bitronix.tm.resource.jms.lrc.LrcXASession
 
createTemporaryTopic() - Method in class bitronix.tm.resource.jms.DualSessionWrapper
 
createTemporaryTopic() - Method in class bitronix.tm.resource.jms.lrc.LrcXASession
 
createTextMessage() - Method in class bitronix.tm.resource.jms.DualSessionWrapper
 
createTextMessage(String) - Method in class bitronix.tm.resource.jms.DualSessionWrapper
 
createTextMessage() - Method in class bitronix.tm.resource.jms.lrc.LrcXASession
 
createTextMessage(String) - Method in class bitronix.tm.resource.jms.lrc.LrcXASession
 
createTopic(String) - Method in class bitronix.tm.resource.jms.DualSessionWrapper
 
createTopic(String) - Method in class bitronix.tm.resource.jms.lrc.LrcXASession
 
createXAConnection() - Method in class bitronix.tm.resource.jms.JndiXAConnectionFactory
 
createXAConnection(String, String) - Method in class bitronix.tm.resource.jms.JndiXAConnectionFactory
 
createXAConnection() - Method in class bitronix.tm.resource.jms.lrc.LrcXAConnectionFactory
 
createXAConnection(String, String) - Method in class bitronix.tm.resource.jms.lrc.LrcXAConnectionFactory
 
createXASession() - Method in class bitronix.tm.resource.jms.lrc.LrcXAConnection
 
crypt(String, String) - Static method in class bitronix.tm.utils.CryptoEngine
Crypt the given data using the given cipher.
currentTransaction() - Static method in class bitronix.tm.resource.common.TransactionContextHelper
Get the transaction running on the current thead context.

D

DEFAULT_POSITION - Static variable in class bitronix.tm.utils.Scheduler
 
DEFAULT_POSITION_KEY - Static variable in class bitronix.tm.utils.Scheduler
 
DanglingTransaction - class bitronix.tm.recovery.DanglingTransaction.
Simple bean containing a unique resource name paired with a XID corresponding to a branch on that resource.
DanglingTransaction(String, Xid) - Constructor for class bitronix.tm.recovery.DanglingTransaction
 
Decoder - class bitronix.tm.utils.Decoder.
Constant to string decoder.
Decoder() - Constructor for class bitronix.tm.utils.Decoder
 
DeferredReleaseSynchronization - class bitronix.tm.resource.common.DeferredReleaseSynchronization.
Synchronization used to release a XAStatefulHolder object after 2PC has executed.
DeferredReleaseSynchronization(XAStatefulHolder) - Constructor for class bitronix.tm.resource.common.DeferredReleaseSynchronization
 
DiskForceBatcherThread - class bitronix.tm.journal.DiskForceBatcherThread.
Thread that executes disk force batches.
DiskForceWaitQueue - class bitronix.tm.journal.DiskForceWaitQueue.
TransactionLogAppenders waiting for a disk force get enqueued here.
DiskForceWaitQueue() - Constructor for class bitronix.tm.journal.DiskForceWaitQueue
 
DiskJournal - class bitronix.tm.journal.DiskJournal.
Simple implementation of a journal that writes on a two-files disk log.
DiskJournal() - Constructor for class bitronix.tm.journal.DiskJournal
Create an uninitialized disk journal.
DualSessionWrapper - class bitronix.tm.resource.jms.DualSessionWrapper.
JMS Session wrapper that will send calls to either a XASession or to a non-XA Session depending on the calling context.
DualSessionWrapper(JmsPooledConnection, boolean, int) - Constructor for class bitronix.tm.resource.jms.DualSessionWrapper
 
DuplicatedGtridTableModel - class bitronix.tm.gui.DuplicatedGtridTableModel.
© Bitronix Software
DuplicatedGtridTableModel(Map) - Constructor for class bitronix.tm.gui.DuplicatedGtridTableModel
 
dateFormatter - Static variable in class bitronix.tm.gui.Console
 
decodeHeaderState(byte) - Static method in class bitronix.tm.utils.Decoder
 
decodePrepareVote(int) - Static method in class bitronix.tm.utils.Decoder
 
decodeStatus(int) - Static method in class bitronix.tm.utils.Decoder
 
decodeXAExceptionErrorCode(XAException) - Static method in class bitronix.tm.utils.Decoder
 
decodeXAResourceFlag(int) - Static method in class bitronix.tm.utils.Decoder
 
decodeXAStatefulHolderState(int) - Static method in class bitronix.tm.utils.Decoder
 
decrypt(String, String) - Static method in class bitronix.tm.utils.CryptoEngine
Decrypt using the given cipher the given base64-encoded, crypted data.
delist(XAResourceHolderState, int) - Method in class bitronix.tm.internal.XAResourceManager
Delist the specified XAResourceHolderState.
delistFromCurrentTransaction(XAResourceHolder) - Static method in class bitronix.tm.resource.common.TransactionContextHelper
Delist the XAResourceHolder from the current transaction or do nothing if there is no global transaction context for this thread.
delistResource(XAResource, int) - Method in class bitronix.tm.BitronixTransaction
 
destroySubcontext(Name) - Method in class bitronix.tm.jndi.BitronixContext
 
destroySubcontext(String) - Method in class bitronix.tm.jndi.BitronixContext
 
doForce() - Method in class bitronix.tm.journal.TransactionLogAppender
 
dumpTransactionContexts() - Method in class bitronix.tm.BitronixTransactionManager
Dump an overview of all running transactions as debug logs.

E

ENDED - Static variable in class bitronix.tm.resource.jdbc.lrc.LrcXAResource
 
ENDED - Static variable in class bitronix.tm.resource.jms.lrc.LrcXAResource
 
END_RECORD - Static variable in class bitronix.tm.journal.TransactionLogAppender
int-encoded "xntB" ASCII string.
EhCacheXAResourceHolder - class bitronix.tm.resource.ehcache.EhCacheXAResourceHolder.
EHCache implementation of BTM's XAResourceHolder.
EhCacheXAResourceHolder(XAResource, ResourceBean) - Constructor for class bitronix.tm.resource.ehcache.EhCacheXAResourceHolder
Create a new EhCacheXAResourceHolder for a particular XAResource
EhCacheXAResourceProducer - class bitronix.tm.resource.ehcache.EhCacheXAResourceProducer.
EHCache implementation of BTM's XAResourceProducer.
Encoder - class bitronix.tm.utils.Encoder.
Number to byte array and byte array to number encoder.
Encoder() - Constructor for class bitronix.tm.utils.Encoder
 
Executor - interface bitronix.tm.twopc.executor.Executor.
Thread pool interface required by the two-phase commit logic.
end(int) - Method in class bitronix.tm.internal.XAResourceHolderState
 
end(Xid, int) - Method in class bitronix.tm.resource.jdbc.lrc.LrcXAResource
 
end(Xid, int) - Method in class bitronix.tm.resource.jms.lrc.LrcXAResource
 
endRecovery() - Method in interface bitronix.tm.resource.common.XAResourceProducer
Release internal resources held after call to startRecovery().
endRecovery() - Method in class bitronix.tm.resource.ehcache.EhCacheXAResourceProducer
Release internal resources held after call to startRecovery().
endRecovery() - Method in class bitronix.tm.resource.jdbc.PoolingDataSource
 
endRecovery() - Method in class bitronix.tm.resource.jms.PoolingConnectionFactory
 
enlist(XAResourceHolderState) - Method in class bitronix.tm.internal.XAResourceManager
Enlist the specified XAResourceHolderState.
enlistInCurrentTransaction(XAResourceHolder) - Static method in class bitronix.tm.resource.common.TransactionContextHelper
Enlist the XAResourceHolder in the current transaction or do nothing if there is no global transaction context for this thread.
enlistResource(XAResource) - Method in class bitronix.tm.BitronixTransaction
 
enlistResource() - Method in class bitronix.tm.resource.jms.DualSessionWrapper
Enlist this session into the current transaction if automaticEnlistingEnabled = true for this resource.
enlistResource() - Method in class bitronix.tm.resource.jms.MessageConsumerWrapper
Enlist this session into the current transaction if automaticEnlistingEnabled = true for this resource.
enlistResource() - Method in class bitronix.tm.resource.jms.MessageProducerWrapper
Enlist this session into the current transaction if automaticEnlistingEnabled = true for this resource.
enqueue(TransactionLogAppender) - Method in class bitronix.tm.journal.DiskForceBatcherThread
Add the TransactionLogAppender to the wait queue and wait until the disk force is done.
enqueue(TransactionLogAppender) - Method in class bitronix.tm.journal.DiskForceWaitQueue
 
equals(Object) - Method in class bitronix.tm.BitronixTransaction
 
equals(Object) - Method in class bitronix.tm.BitronixXid
Compare two XIDs for equality.
equals(Object) - Method in class bitronix.tm.internal.XAResourceHolderState
 
equals(Object) - Method in class bitronix.tm.recovery.DanglingTransaction
 
equals(Object) - Method in class bitronix.tm.resource.jdbc.JdbcPreparedStatementHandle
Overridden equals() that takes all PreparedStatement attributes into account.
equals(Object) - Method in class bitronix.tm.resource.jdbc.lrc.LrcXAConnection
 
equals(Object) - Method in class bitronix.tm.resource.jms.MessageProducerConsumerKey
 
equals(Object) - Method in class bitronix.tm.utils.Uid
 
execute() - Method in class bitronix.tm.timer.PoolShrinkingTask
 
execute() - Method in class bitronix.tm.timer.RecoveryTask
 
execute() - Method in class bitronix.tm.timer.Task
 
execute() - Method in class bitronix.tm.timer.TransactionTimeoutTask
 
execute() - Method in class bitronix.tm.twopc.executor.Job
 
executePhase(XAResourceManager, boolean) - Method in class bitronix.tm.twopc.AbstractPhaseEngine
Execute the phase.
extractSequence() - Method in class bitronix.tm.utils.Uid
 
extractServerId() - Method in class bitronix.tm.utils.Uid
 
extractTimestamp() - Method in class bitronix.tm.utils.Uid
 

F

FORMAT_ID - Static variable in class bitronix.tm.BitronixXid
int-encoded "Btnx" string.
FORMAT_ID_HEADER - Static variable in class bitronix.tm.journal.TransactionLogHeader
Position of the format ID in the header (see BitronixXid.FORMAT_ID).
filterByGtrid(String) - Method in class bitronix.tm.gui.RawTransactionTableModel
 
findXAResourceHolder(XAResource) - Static method in class bitronix.tm.resource.ResourceRegistrar
Find in the registered XAResourceProducers the XAResourceHolder from which the specified XAResource comes from.
findXAResourceHolder(XAResource) - Method in class bitronix.tm.resource.common.XAPool
 
findXAResourceHolder(XAResource) - Method in interface bitronix.tm.resource.common.XAResourceProducer
Find in the XAResourceHolders created by this XAResourceProducer the one which this XAResource belongs to.
findXAResourceHolder(XAResource) - Method in class bitronix.tm.resource.ehcache.EhCacheXAResourceProducer
Find in the XAResourceHolders created by this XAResourceProducer the one which this XAResource belongs to.
findXAResourceHolder(XAResource) - Method in class bitronix.tm.resource.jdbc.PoolingDataSource
 
findXAResourceHolder(XAResource) - Method in class bitronix.tm.resource.jms.PoolingConnectionFactory
 
findXAResourceHolderState(XAResource) - Method in class bitronix.tm.internal.XAResourceManager
Look if an XAResource has already been enlisted.
force() - Method in class bitronix.tm.journal.DiskJournal
Force active log file to synchronize with the underlying disk device.
force() - Method in interface bitronix.tm.journal.Journal
Force journal to synchronize with permanent storage.
force() - Method in class bitronix.tm.journal.NullJournal
 
force() - Method in class bitronix.tm.journal.TransactionLogAppender
Force flushing the logs to disk
forget(Xid) - Method in class bitronix.tm.resource.jdbc.lrc.LrcXAResource
 
forget(Xid) - Method in class bitronix.tm.resource.jms.lrc.LrcXAResource
 

G

GTRID_COL - Static variable in class bitronix.tm.gui.RawTransactionTableModel
 
generateUid() - Static method in class bitronix.tm.utils.UidGenerator
Generate a UID, globally unique.
generateXid(Uid) - Static method in class bitronix.tm.utils.UidGenerator
Generate a XID with the specified globalTransactionId.
get(String) - Static method in class bitronix.tm.resource.ResourceRegistrar
Get a registered XAResourceProducer.
get(JdbcPreparedStatementHandle) - Method in class bitronix.tm.resource.jdbc.LruStatementCache
The provided key is just a 'shell' JdbcPreparedStatementHandle, it comes in with no actual 'delegate' PreparedStatement.
getAcknowledgeMode() - Method in class bitronix.tm.resource.jms.DualSessionWrapper
 
getAcknowledgeMode() - Method in class bitronix.tm.resource.jms.lrc.LrcXASession
 
getAcquireIncrement() - Method in class bitronix.tm.resource.common.ResourceBean
 
getAcquisitionDate() - Method in class bitronix.tm.resource.jdbc.JdbcPooledConnection
 
getAcquisitionDate() - Method in interface bitronix.tm.resource.jdbc.JdbcPooledConnectionMBean
 
getAcquisitionDate() - Method in class bitronix.tm.resource.jms.JmsPooledConnection
 
getAcquisitionDate() - Method in interface bitronix.tm.resource.jms.JmsPooledConnectionMBean
 
getAcquisitionInterval() - Method in class bitronix.tm.resource.common.ResourceBean
 
getAcquisitionTimeout() - Method in class bitronix.tm.resource.common.ResourceBean
 
getAllResources() - Method in class bitronix.tm.internal.XAResourceManager
 
getAllowLocalTransactions() - Method in class bitronix.tm.resource.common.ResourceBean
 
getApplyTransactionTimeout() - Method in class bitronix.tm.resource.common.ResourceBean
 
getArray() - Method in class bitronix.tm.utils.Uid
 
getAutoCommit() - Method in class bitronix.tm.resource.jdbc.JdbcConnectionHandle
 
getAutomaticEnlistingEnabled() - Method in class bitronix.tm.resource.common.ResourceBean
 
getBackgroundRecoveryInterval() - Method in class bitronix.tm.Configuration
Deprecated. superceded by #getBackgroundRecoveryIntervalSeconds().
getBackgroundRecoveryIntervalSeconds() - Method in class bitronix.tm.Configuration
Interval in seconds at which to run the recovery process in the background.
getBranchQualifier() - Method in class bitronix.tm.BitronixXid
Get the BQUAL of the XID.
getBranchQualifierUid() - Method in class bitronix.tm.BitronixXid
 
getByNaturalOrderForPosition(Object) - Method in class bitronix.tm.utils.Scheduler
 
getByReverseOrderForPosition(Object) - Method in class bitronix.tm.utils.Scheduler
 
getCacheProducersConsumers() - Method in class bitronix.tm.resource.jms.PoolingConnectionFactory
 
getCachedStatement(JdbcPreparedStatementHandle) - Method in class bitronix.tm.resource.jdbc.JdbcPooledConnection
Get a PreparedStatement from cache.
getChild(Object, int) - Method in class bitronix.tm.gui.ResourcesTreeModel
 
getChildCount(Object) - Method in class bitronix.tm.gui.ResourcesTreeModel
 
getClassLoader() - Static method in class bitronix.tm.utils.ClassLoaderUtils
Get the class loader which can be used to generate proxies without leaking memory.
getClassName() - Method in class bitronix.tm.resource.common.ResourceBean
 
getClientID() - Method in class bitronix.tm.resource.jms.JmsConnectionHandle
 
getClientID() - Method in class bitronix.tm.resource.jms.lrc.LrcXAConnection
 
getColumnClass(int) - Method in class bitronix.tm.gui.PendingTransactionTableModel
 
getColumnClass(int) - Method in class bitronix.tm.gui.RawTransactionTableModel
 
getColumnCount() - Method in class bitronix.tm.gui.PendingTransactionTableModel
 
getColumnCount() - Method in class bitronix.tm.gui.RawTransactionTableModel
 
getColumnName(int) - Method in class bitronix.tm.gui.DuplicatedGtridTableModel
 
getColumnName(int) - Method in class bitronix.tm.gui.PendingTransactionTableModel
 
getColumnName(int) - Method in class bitronix.tm.gui.RawTransactionTableModel
 
getCommittedCount() - Method in class bitronix.tm.recovery.Recoverer
Get the amount of transactions committed during the last recovery run.
getCommittedCount() - Method in interface bitronix.tm.recovery.RecovererMBean
 
getCompletionException() - Method in class bitronix.tm.recovery.Recoverer
Get the exception reported when recovery failed.
getCompletionException() - Method in interface bitronix.tm.recovery.RecovererMBean
 
getConfiguration() - Static method in class bitronix.tm.TransactionManagerServices
Create the configuration of all the components of the transaction manager.
getConnection() - Method in class bitronix.tm.resource.jdbc.JdbcConnectionHandle
 
getConnection() - Method in class bitronix.tm.resource.jdbc.PoolingDataSource
 
getConnection(String, String) - Method in class bitronix.tm.resource.jdbc.PoolingDataSource
 
getConnection() - Method in class bitronix.tm.resource.jdbc.lrc.LrcConnectionHandle
 
getConnection() - Method in class bitronix.tm.resource.jdbc.lrc.LrcXAConnection
 
getConnectionFactoryClassName() - Method in class bitronix.tm.resource.jms.lrc.LrcXAConnectionFactory
 
getConnectionHandle() - Method in class bitronix.tm.resource.common.RecoveryXAResourceHolder
 
getConnectionHandle() - Method in class bitronix.tm.resource.common.XAPool
 
getConnectionHandle(boolean) - Method in class bitronix.tm.resource.common.XAPool
 
getConnectionHandle() - Method in interface bitronix.tm.resource.common.XAStatefulHolder
Create a disposable handler used to drive a pooled instance of XAStatefulHolder.
getConnectionHandle() - Method in class bitronix.tm.resource.ehcache.EhCacheXAResourceHolder
Create a disposable handler used to drive a pooled instance of XAStatefulHolder.

This method is thread-safe.

getConnectionHandle() - Method in class bitronix.tm.resource.jdbc.JdbcPooledConnection
 
getConnectionHandle() - Method in class bitronix.tm.resource.jms.DualSessionWrapper
 
getConnectionHandle() - Method in class bitronix.tm.resource.jms.JmsPooledConnection
 
getCrc32() - Method in class bitronix.tm.journal.TransactionLogRecord
 
getCurrentTransaction() - Method in class bitronix.tm.BitronixTransactionManager
Get the transaction currently registered on the current thread context.
getCursor() - Method in class bitronix.tm.journal.TransactionLogAppender
Creates a cursor on this journal file allowing iteration of its records.
getCursorHoldability() - Method in class bitronix.tm.resource.jdbc.PoolingDataSource
 
getDefaultTransactionTimeout() - Method in class bitronix.tm.Configuration
Default transaction timeout in seconds.
getDeferConnectionRelease() - Method in class bitronix.tm.resource.common.ResourceBean
 
getDelegateUnchecked() - Method in class bitronix.tm.resource.jdbc.JdbcPreparedStatementHandle
 
getDeliveryMode() - Method in class bitronix.tm.resource.jms.MessageProducerWrapper
 
getDestination() - Method in class bitronix.tm.resource.jms.MessageProducerWrapper
 
getDisableMessageID() - Method in class bitronix.tm.resource.jms.MessageProducerWrapper
 
getDisableMessageTimestamp() - Method in class bitronix.tm.resource.jms.MessageProducerWrapper
 
getDriverClassName() - Method in class bitronix.tm.resource.jdbc.lrc.LrcXADataSource
 
getDriverProperties() - Method in class bitronix.tm.resource.common.ResourceBean
 
getEndRecord() - Method in class bitronix.tm.journal.TransactionLogRecord
 
getEnlistedResourcesUniqueNames() - Method in class bitronix.tm.BitronixTransaction
 
getEnlistedResourcesUniqueNames() - Method in interface bitronix.tm.BitronixTransactionMBean
 
getEnvironment() - Method in class bitronix.tm.jndi.BitronixContext
 
getExceptionListener() - Method in class bitronix.tm.resource.jms.JmsConnectionHandle
 
getExceptionListener() - Method in class bitronix.tm.resource.jms.lrc.LrcXAConnection
 
getExceptions() - Method in class bitronix.tm.internal.BitronixMultiSystemException
Get the list of exceptions that have been thrown during execution.
getExceptions() - Method in class bitronix.tm.twopc.PhaseException
Get the list of exceptions that have been thrown during a phase execution.
getExecutionTime() - Method in class bitronix.tm.timer.Task
 
getExecutionsCount() - Method in class bitronix.tm.recovery.Recoverer
Get how many times the recoverer has run since the transaction manager started.
getExecutionsCount() - Method in interface bitronix.tm.recovery.RecovererMBean
 
getExecutor() - Static method in class bitronix.tm.TransactionManagerServices
Create the 2PC executor.
getExtraJndiProperties() - Method in class bitronix.tm.resource.jms.JndiXAConnectionFactory
The extra JNDI environment properties added the the InitialContext's environment upon creation.
getFormatId() - Method in class bitronix.tm.BitronixXid
Get Bitronix XID format ID.
getFormatId() - Method in class bitronix.tm.journal.TransactionLogHeader
Get FORMAT_ID_HEADER.
getFuture() - Method in class bitronix.tm.twopc.executor.Job
 
getGlobalTransactionId() - Method in class bitronix.tm.BitronixXid
Get the GTRID of the XID.
getGlobalTransactionIdUid() - Method in class bitronix.tm.BitronixXid
 
getGracefulShutdownInterval() - Method in class bitronix.tm.Configuration
Maximum amount of seconds the TM will wait for transactions to get done before aborting them at shutdown time.
getGtrid() - Method in class bitronix.tm.BitronixTransaction
 
getGtrid() - Method in interface bitronix.tm.BitronixTransactionMBean
 
getGtrid() - Method in class bitronix.tm.internal.XAResourceManager
Get the GTRID of the transaction the XAResourceManager instance is attached to.
getGtrid() - Method in class bitronix.tm.journal.TransactionLogRecord
 
getHeader() - Method in class bitronix.tm.journal.TransactionLogAppender
Return a TransactionLogHeader that allows reading and controlling the log file's header.
getHeaderLength() - Method in class bitronix.tm.journal.TransactionLogRecord
 
getInFlightTransactions() - Method in class bitronix.tm.BitronixTransactionManager
Return all in-flight transactions.
getInPoolSize() - Method in class bitronix.tm.resource.jdbc.PoolingDataSource
 
getInPoolSize() - Method in interface bitronix.tm.resource.jdbc.PoolingDataSourceMBean
 
getInPoolSize() - Method in class bitronix.tm.resource.jms.PoolingConnectionFactory
 
getInPoolSize() - Method in interface bitronix.tm.resource.jms.PoolingConnectionFactoryMBean
 
getIndexOfChild(Object, Object) - Method in class bitronix.tm.gui.ResourcesTreeModel
 
getInitialContext(Hashtable) - Method in class bitronix.tm.jndi.BitronixInitialContextFactory
 
getInitialContextFactory() - Method in class bitronix.tm.resource.jms.JndiXAConnectionFactory
The Context.INITIAL_CONTEXT_FACTORY of the JNDI Context used to fetch the XAConnectionFactory.
getInstance() - Static method in class bitronix.tm.journal.DiskForceBatcherThread
Get the single instance of the DiskForceBatcherThread.
getIsolationLevel() - Method in class bitronix.tm.resource.jdbc.PoolingDataSource
 
getJndiTransactionSynchronizationRegistryName() - Method in class bitronix.tm.Configuration
Get the name the TransactionSynchronizationRegistry should be bound under in the BitronixContext.
getJndiUserTransactionName() - Method in class bitronix.tm.Configuration
Get the name the UserTransaction should be bound under in the BitronixContext.
getJournal() - Method in class bitronix.tm.Configuration
Get the journal implementation.
getJournal() - Static method in class bitronix.tm.TransactionManagerServices
Create the transactions journal.
getLastReleaseDate() - Method in class bitronix.tm.resource.common.RecoveryXAResourceHolder
 
getLastReleaseDate() - Method in interface bitronix.tm.resource.common.XAStatefulHolder
Get the date at which this object was last released to the pool.
getLastReleaseDate() - Method in class bitronix.tm.resource.ehcache.EhCacheXAResourceHolder
Get the date at which this object was last released to the pool. This is required to check if it is eligible for discard when the containing pool needs to shrink.
getLastReleaseDate() - Method in class bitronix.tm.resource.jdbc.JdbcPooledConnection
 
getLastReleaseDate() - Method in class bitronix.tm.resource.jms.DualSessionWrapper
 
getLastReleaseDate() - Method in class bitronix.tm.resource.jms.JmsPooledConnection
 
getLocalAutoCommit() - Method in class bitronix.tm.resource.jdbc.PoolingDataSource
 
getLogPart1Filename() - Method in class bitronix.tm.Configuration
Get the journal fragment file 1 name.
getLogPart2Filename() - Method in class bitronix.tm.Configuration
Get the journal fragment file 2 name.
getLogWriter() - Method in class bitronix.tm.resource.jdbc.PoolingDataSource
 
getLogWriter() - Method in class bitronix.tm.resource.jdbc.lrc.LrcXADataSource
 
getLoginTimeout() - Method in class bitronix.tm.resource.jdbc.PoolingDataSource
 
getLoginTimeout() - Method in class bitronix.tm.resource.jdbc.lrc.LrcXADataSource
 
getMaxIdleTime() - Method in class bitronix.tm.resource.common.ResourceBean
 
getMaxLogSizeInMb() - Method in class bitronix.tm.Configuration
Maximum size in megabytes of the journal fragments.
getMaxPoolSize() - Method in class bitronix.tm.resource.common.ResourceBean
 
getMessage() - Method in class bitronix.tm.internal.BitronixMultiSystemException
 
getMessage() - Method in class bitronix.tm.twopc.PhaseException
 
getMessageConsumer() - Method in class bitronix.tm.resource.jms.MessageConsumerWrapper
 
getMessageListener() - Method in class bitronix.tm.resource.jms.DualSessionWrapper
 
getMessageListener() - Method in class bitronix.tm.resource.jms.MessageConsumerWrapper
 
getMessageListener() - Method in class bitronix.tm.resource.jms.lrc.LrcXASession
 
getMessageProducer() - Method in class bitronix.tm.resource.jms.MessageProducerWrapper
 
getMessageSelector() - Method in class bitronix.tm.resource.jms.MessageConsumerWrapper
 
getMetaData() - Method in class bitronix.tm.resource.jms.JmsConnectionHandle
 
getMetaData() - Method in class bitronix.tm.resource.jms.lrc.LrcXAConnection
 
getMinPoolSize() - Method in class bitronix.tm.resource.common.ResourceBean
 
getName() - Method in class bitronix.tm.resource.jms.JndiXAConnectionFactory
The JNDI name under which the XAConnectionFactory is available.
getNameInNamespace() - Method in class bitronix.tm.jndi.BitronixContext
 
getNameParser(Name) - Method in class bitronix.tm.jndi.BitronixContext
 
getNameParser(String) - Method in class bitronix.tm.jndi.BitronixContext
 
getNaturalOrderPositions() - Method in class bitronix.tm.internal.XAResourceManager
 
getNaturalOrderPositions() - Method in class bitronix.tm.utils.Scheduler
 
getNaturalOrderResourcesForPosition(Object) - Method in class bitronix.tm.internal.XAResourceManager
 
getNextSequenceNumber() - Static method in class bitronix.tm.utils.UidGenerator
Atomically generate general-purpose sequence numbers starting at 0.
getNextShrinkDate() - Method in class bitronix.tm.resource.common.XAPool
 
getNoLocal() - Method in class bitronix.tm.resource.jms.TopicSubscriberWrapper
 
getObject() - Method in class bitronix.tm.timer.PoolShrinkingTask
 
getObject() - Method in class bitronix.tm.timer.RecoveryTask
 
getObject() - Method in class bitronix.tm.timer.Task
 
getObject() - Method in class bitronix.tm.timer.TransactionTimeoutTask
 
getObjectInstance(Object, Name, Context, Hashtable) - Method in class bitronix.tm.BitronixTransactionManagerObjectFactory
Since there can be only one transaction manager per VM instance, this method always returns a reference to the unique BitronixTransactionManager object.
getObjectInstance(Object, Name, Context, Hashtable) - Method in class bitronix.tm.BitronixTransactionSynchronizationRegistryObjectFactory
Since there can be only one synchronization registry per VM instance, this method always returns a reference to the unique BitronixTransactionSynchronizationRegistry object.
getObjectInstance(Object, Name, Context, Hashtable) - Method in class bitronix.tm.resource.ResourceObjectFactory
 
getOldestInFlightTransactionTimestamp() - Method in class bitronix.tm.BitronixTransactionManager
Return the timestamp of the oldest in-flight transaction.
getPassword() - Method in class bitronix.tm.resource.jdbc.lrc.LrcXADataSource
 
getPassword() - Method in class bitronix.tm.resource.jms.PoolingConnectionFactory
 
getPooledConnection() - Method in class bitronix.tm.resource.jdbc.JdbcConnectionHandle
 
getPooledConnection() - Method in class bitronix.tm.resource.jdbc.JdbcPreparedStatementHandle
 
getPooledConnection() - Method in class bitronix.tm.resource.jms.JmsConnectionHandle
 
getPoolingConnectionFactory() - Method in class bitronix.tm.resource.jms.DualSessionWrapper
 
getPoolingConnectionFactory() - Method in class bitronix.tm.resource.jms.JmsPooledConnection
 
getPoolingDataSource() - Method in class bitronix.tm.resource.jdbc.JdbcPooledConnection
 
getPosition() - Method in class bitronix.tm.journal.TransactionLogHeader
Get CURRENT_POSITION_HEADER.
getPreparedStatementCacheSize() - Method in class bitronix.tm.resource.jdbc.PoolingDataSource
 
getPriority() - Method in class bitronix.tm.resource.jms.MessageProducerWrapper
 
getProperties() - Method in class bitronix.tm.resource.jms.lrc.LrcXAConnectionFactory
 
getProperties(Object) - Static method in class bitronix.tm.utils.PropertyUtils
Build a map of direct javabeans properties of the target object.
getProperty(Object, String) - Static method in class bitronix.tm.utils.PropertyUtils
Get a direct or indirect property (dotted property: prop1.prop2.prop3) on the target object.
getProviderUrl() - Method in class bitronix.tm.resource.jms.JndiXAConnectionFactory
The Context.PROVIDER_URL of the JNDI Context used to fetch the XAConnectionFactory.
getProxiedDelegate() - Method in class bitronix.tm.resource.jdbc.BaseProxyHandlerClass
Must be implemented by the sub-class of this class.
getProxiedDelegate() - Method in class bitronix.tm.resource.jdbc.JdbcCallableStatementHandle
 
getProxiedDelegate() - Method in class bitronix.tm.resource.jdbc.JdbcConnectionHandle
 
getProxiedDelegate() - Method in class bitronix.tm.resource.jdbc.JdbcPreparedStatementHandle
 
getProxiedDelegate() - Method in class bitronix.tm.resource.jdbc.JdbcStatementHandle
 
getProxiedDelegate() - Method in class bitronix.tm.resource.jdbc.JdbcUncachedPreparedStatementHandle
 
getProxiedDelegate() - Method in class bitronix.tm.resource.jdbc.lrc.LrcConnectionHandle
 
getProxiedDelegate() - Method in class bitronix.tm.resource.jdbc.lrc.LrcXAConnection
 
getRecordLength() - Method in class bitronix.tm.journal.TransactionLogRecord
 
getRecoverer() - Static method in class bitronix.tm.TransactionManagerServices
Create the transaction recoverer.
getReference() - Method in class bitronix.tm.BitronixTransactionManager
BitronixTransactionManager can only have a single instance per JVM so this method always returns a reference with no special information to find back the sole instance.
getReference() - Method in class bitronix.tm.BitronixTransactionSynchronizationRegistry
 
getReference() - Method in class bitronix.tm.resource.ehcache.EhCacheXAResourceProducer
getReference() - Method in class bitronix.tm.resource.jdbc.PoolingDataSource
PoolingDataSource must alway have a unique name so this method builds a reference to this object using the unique name as RefAddr.
getReference() - Method in class bitronix.tm.resource.jms.PoolingConnectionFactory
PoolingConnectionFactory must alway have a unique name so this method builds a reference to this object using the unique name as RefAddr.
getResource(Object) - Method in class bitronix.tm.BitronixTransactionSynchronizationRegistry
 
getResource() - Method in class bitronix.tm.twopc.executor.Job
 
getResourceAsStream(String) - Static method in class bitronix.tm.utils.ClassLoaderUtils
Load a resource from the classpath.
getResourceBean() - Method in class bitronix.tm.resource.common.RecoveryXAResourceHolder
 
getResourceBean() - Method in interface bitronix.tm.resource.common.XAResourceHolder
Get the ResourceBean which created this XAResourceHolder.
getResourceBean() - Method in class bitronix.tm.resource.ehcache.EhCacheXAResourceHolder
Get the ResourceBean which created this XAResourceHolder.
getResourceBean() - Method in class bitronix.tm.resource.jdbc.JdbcPooledConnection
 
getResourceBean() - Method in class bitronix.tm.resource.jms.DualSessionWrapper
 
getResourceConfigurationFilename() - Method in class bitronix.tm.Configuration
ResourceLoader configuration file name.
getResourceLoader() - Static method in class bitronix.tm.TransactionManagerServices
Create the resource loader.
getResourceManager() - Method in class bitronix.tm.BitronixTransaction
 
getResourceStates() - Method in class bitronix.tm.internal.BitronixMultiSystemException
Get the list of XAResourceHolderStates which threw an exception during execution.
getResourceStates() - Method in class bitronix.tm.twopc.PhaseException
Get the list of resource which threw an exception during a phase execution.
getResources() - Method in class bitronix.tm.resource.ResourceLoader
Get a Map with the configured uniqueName as key and XAResourceProducer as value.
getResourcesUniqueNames() - Static method in class bitronix.tm.resource.ResourceRegistrar
Get all XAResourceProducers unique names.
getReverseOrderPositions() - Method in class bitronix.tm.internal.XAResourceManager
 
getReverseOrderPositions() - Method in class bitronix.tm.utils.Scheduler
 
getReverseOrderResourcesForPosition(Object) - Method in class bitronix.tm.internal.XAResourceManager
 
getRollbackOnly() - Method in class bitronix.tm.BitronixTransactionSynchronizationRegistry
 
getRolledbackCount() - Method in class bitronix.tm.recovery.Recoverer
Get the amount of transactions rolled back during the last recovery run.
getRolledbackCount() - Method in interface bitronix.tm.recovery.RecovererMBean
 
getRoot() - Method in class bitronix.tm.gui.ResourcesTreeModel
 
getRow(int) - Method in class bitronix.tm.gui.PendingTransactionTableModel
 
getRow(int) - Method in class bitronix.tm.gui.RawTransactionTableModel
 
getRow(int) - Method in class bitronix.tm.gui.TransactionTableModel
 
getRowCount() - Method in class bitronix.tm.gui.PendingTransactionTableModel
 
getRowCount() - Method in class bitronix.tm.gui.RawTransactionTableModel
 
getRuntimeException() - Method in class bitronix.tm.twopc.executor.Job
 
getSecurityCredentials() - Method in class bitronix.tm.resource.jms.JndiXAConnectionFactory
The Context.SECURITY_CREDENTIALS of the JNDI Context used to fetch the XAConnectionFactory.
getSecurityPrincipal() - Method in class bitronix.tm.resource.jms.JndiXAConnectionFactory
The Context.SECURITY_PRINCIPAL of the JNDI Context used to fetch the XAConnectionFactory.
getSequenceNumber() - Method in class bitronix.tm.journal.TransactionLogRecord
 
getServerId() - Method in class bitronix.tm.Configuration
ASCII ID that must uniquely identify this TM instance.
getSession() - Method in class bitronix.tm.resource.jms.DualSessionWrapper
 
getSession(boolean) - Method in class bitronix.tm.resource.jms.DualSessionWrapper
 
getSession() - Method in class bitronix.tm.resource.jms.lrc.LrcXASession
 
getShareTransactionConnections() - Method in class bitronix.tm.resource.common.ResourceBean
 
getStartDate() - Method in class bitronix.tm.BitronixTransaction
 
getStartDate() - Method in interface bitronix.tm.BitronixTransactionMBean
 
getState() - Method in class bitronix.tm.journal.TransactionLogHeader
Get STATE_HEADER.
getState() - Method in class bitronix.tm.resource.common.AbstractXAStatefulHolder
 
getState() - Method in interface bitronix.tm.resource.common.XAStatefulHolder
Get the current resource state.
getState() - Method in class bitronix.tm.resource.jdbc.lrc.LrcXAResource
 
getState() - Method in class bitronix.tm.resource.jms.lrc.LrcXAResource
 
getStateDescription() - Method in class bitronix.tm.resource.jdbc.JdbcPooledConnection
 
getStateDescription() - Method in interface bitronix.tm.resource.jdbc.JdbcPooledConnectionMBean
 
getStateDescription() - Method in class bitronix.tm.resource.jms.JmsPooledConnection
 
getStateDescription() - Method in interface bitronix.tm.resource.jms.JmsPooledConnectionMBean
 
getStatus() - Method in class bitronix.tm.BitronixTransaction
 
getStatus() - Method in class bitronix.tm.BitronixTransactionManager
 
getStatus() - Method in class bitronix.tm.journal.TransactionLogRecord
 
getStatusDescription() - Method in class bitronix.tm.BitronixTransaction
 
getStatusDescription() - Method in interface bitronix.tm.BitronixTransactionMBean
 
getSynchronizationScheduler() - Method in class bitronix.tm.BitronixTransaction
 
getTableCellRendererComponent(JTable, Object, boolean, boolean, int, int) - Method in class bitronix.tm.gui.TransactionTableCellRenderer
 
getTaskScheduler() - Static method in class bitronix.tm.TransactionManagerServices
Create the task scheduler.
getTaskScheduler() - Method in class bitronix.tm.timer.Task
 
getTestConnections() - Method in class bitronix.tm.resource.jms.PoolingConnectionFactory
 
getTestQuery() - Method in class bitronix.tm.resource.jdbc.PoolingDataSource
 
getThreadName() - Method in class bitronix.tm.BitronixTransaction
 
getThreadName() - Method in interface bitronix.tm.BitronixTransactionMBean
 
getTime() - Method in class bitronix.tm.journal.TransactionLogRecord
 
getTimeToLive() - Method in class bitronix.tm.resource.jms.MessageProducerWrapper
 
getTimeout() - Method in class bitronix.tm.internal.ThreadContext
Return this context's default timeout.
getTimestamp() - Method in class bitronix.tm.journal.TransactionLogHeader
Get TIMESTAMP_HEADER.
getTopic() - Method in class bitronix.tm.resource.jms.TopicSubscriberWrapper
 
getTotalPoolSize() - Method in class bitronix.tm.resource.jdbc.PoolingDataSource
 
getTotalPoolSize() - Method in interface bitronix.tm.resource.jdbc.PoolingDataSourceMBean
 
getTotalPoolSize() - Method in class bitronix.tm.resource.jms.PoolingConnectionFactory
 
getTotalPoolSize() - Method in interface bitronix.tm.resource.jms.PoolingConnectionFactoryMBean
 
getTransacted() - Method in class bitronix.tm.resource.jms.DualSessionWrapper
 
getTransacted() - Method in class bitronix.tm.resource.jms.lrc.LrcXASession
 
getTransaction() - Method in class bitronix.tm.BitronixTransactionManager
 
getTransaction() - Method in class bitronix.tm.internal.ThreadContext
Return the transaction linked with this thread context.
getTransactionGtridsCurrentlyHoldingThis() - Method in class bitronix.tm.resource.jdbc.JdbcPooledConnection
 
getTransactionGtridsCurrentlyHoldingThis() - Method in interface bitronix.tm.resource.jdbc.JdbcPooledConnectionMBean
 
getTransactionGtridsCurrentlyHoldingThis() - Method in class bitronix.tm.resource.jms.JmsPooledConnection
 
getTransactionGtridsCurrentlyHoldingThis() - Method in interface bitronix.tm.resource.jms.JmsPooledConnectionMBean
 
getTransactionKey() - Method in class bitronix.tm.BitronixTransactionSynchronizationRegistry
 
getTransactionManager() - Static method in class bitronix.tm.TransactionManagerServices
Create an initialized transaction manager.
getTransactionStatus() - Method in class bitronix.tm.BitronixTransactionSynchronizationRegistry
 
getTransactionSynchronizationRegistry() - Static method in class bitronix.tm.TransactionManagerServices
Create the JTA 1.1 TransactionSynchronizationRegistry.
getTransactionTimeout() - Method in class bitronix.tm.resource.jdbc.lrc.LrcXAResource
 
getTransactionTimeout() - Method in class bitronix.tm.resource.jms.lrc.LrcXAResource
 
getTransactionTimeoutDate() - Method in class bitronix.tm.internal.XAResourceHolderState
 
getTwoPcOrderingPosition() - Method in class bitronix.tm.internal.XAResourceHolderState
 
getTwoPcOrderingPosition() - Method in class bitronix.tm.resource.common.ResourceBean
 
getUniqueName() - Method in class bitronix.tm.internal.XAResourceHolderState
 
getUniqueName() - Method in class bitronix.tm.recovery.DanglingTransaction
 
getUniqueName() - Method in class bitronix.tm.resource.common.ResourceBean
 
getUniqueName() - Method in interface bitronix.tm.resource.common.XAResourceProducer
Get the resource name as registered in the transactions journal.
getUniqueNames() - Method in class bitronix.tm.journal.TransactionLogRecord
 
getUrl() - Method in class bitronix.tm.resource.jdbc.lrc.LrcXADataSource
 
getUrlPkgPrefixes() - Method in class bitronix.tm.resource.jms.JndiXAConnectionFactory
The Context.URL_PKG_PREFIXES of the JNDI Context used to fetch the XAConnectionFactory.
getUseTmJoin() - Method in class bitronix.tm.internal.XAResourceHolderState
 
getUseTmJoin() - Method in class bitronix.tm.resource.common.ResourceBean
 
getUser() - Method in class bitronix.tm.resource.jdbc.lrc.LrcXADataSource
 
getUser() - Method in class bitronix.tm.resource.jms.PoolingConnectionFactory
 
getValueAt(int, int) - Method in class bitronix.tm.gui.DuplicatedGtridTableModel
 
getValueAt(int, int) - Method in class bitronix.tm.gui.PendingTransactionTableModel
 
getValueAt(int, int) - Method in class bitronix.tm.gui.RawTransactionTableModel
 
getXAConnection() - Method in class bitronix.tm.resource.jdbc.lrc.LrcXADataSource
 
getXAConnection(String, String) - Method in class bitronix.tm.resource.jdbc.lrc.LrcXADataSource
 
getXAConnection() - Method in class bitronix.tm.resource.jms.JmsConnectionHandle
 
getXAConnection() - Method in class bitronix.tm.resource.jms.JmsPooledConnection
 
getXAException() - Method in class bitronix.tm.twopc.executor.Job
 
getXAFactory() - Method in class bitronix.tm.resource.common.XAPool
 
getXAResource() - Method in class bitronix.tm.internal.XAResourceHolderState
 
getXAResource() - Method in class bitronix.tm.resource.common.RecoveryXAResourceHolder
 
getXAResource() - Method in interface bitronix.tm.resource.common.XAResourceHolder
Get the vendor's XAResource implementation of the wrapped resource.
getXAResource() - Method in class bitronix.tm.resource.ehcache.EhCacheXAResourceHolder
Get the vendor's XAResource implementation of the wrapped resource.
getXAResource() - Method in class bitronix.tm.resource.jdbc.JdbcPooledConnection
 
getXAResource() - Method in class bitronix.tm.resource.jdbc.lrc.LrcXAConnection
 
getXAResource() - Method in class bitronix.tm.resource.jms.DualSessionWrapper
 
getXAResource() - Method in class bitronix.tm.resource.jms.lrc.LrcXASession
 
getXAResourceHolder() - Method in class bitronix.tm.internal.XAResourceHolderState
 
getXAResourceHolderStateGtrids() - Method in class bitronix.tm.resource.common.AbstractXAResourceHolder
Simple helper method which returns a set of GTRIDs of transactions in which this resource is enlisted.
getXAResourceHolderStatesForGtrid(Uid) - Method in class bitronix.tm.resource.common.AbstractXAResourceHolder
 
getXAResourceHolderStatesForGtrid(Uid) - Method in interface bitronix.tm.resource.common.XAResourceHolder
Get all the XAResourceHolderStates of this wrapped resource for a specific GTRID.
getXAResourceHolders() - Method in class bitronix.tm.resource.common.RecoveryXAResourceHolder
 
getXAResourceHolders() - Method in class bitronix.tm.resource.common.XAPool
 
getXAResourceHolders() - Method in interface bitronix.tm.resource.common.XAStatefulHolder
Get the list of XAResourceHolders created by this XAStatefulHolder that are still open.
getXAResourceHolders() - Method in class bitronix.tm.resource.ehcache.EhCacheXAResourceHolder
Get the list of XAResourceHolders created by this XAStatefulHolder that are still open.

This method is thread-safe.

getXAResourceHolders() - Method in class bitronix.tm.resource.jdbc.JdbcPooledConnection
 
getXAResourceHolders() - Method in class bitronix.tm.resource.jms.DualSessionWrapper
 
getXAResourceHolders() - Method in class bitronix.tm.resource.jms.JmsPooledConnection
 
getXAStatefulHolder() - Method in class bitronix.tm.resource.common.DeferredReleaseSynchronization
 
getXid() - Method in class bitronix.tm.internal.XAResourceHolderState
 
getXid() - Method in class bitronix.tm.recovery.DanglingTransaction
 
goAhead(long) - Method in class bitronix.tm.journal.TransactionLogHeader
Advance CURRENT_POSITION_HEADER.

H

HEADER_LENGTH - Static variable in class bitronix.tm.journal.TransactionLogHeader
Total length of the header.
hasStateForXAResource(XAResourceHolder) - Method in class bitronix.tm.resource.common.AbstractXAResourceHolder
 
hasStateForXAResource(XAResourceHolder) - Method in interface bitronix.tm.resource.common.XAResourceHolder
Check if this XAResourceHolder contains a state for a specific XAResourceHolder.
hashCode() - Method in class bitronix.tm.BitronixTransaction
 
hashCode() - Method in class bitronix.tm.BitronixXid
Get an integer hash for the XID.
hashCode() - Method in class bitronix.tm.internal.XAResourceHolderState
 
hashCode() - Method in class bitronix.tm.recovery.DanglingTransaction
 
hashCode() - Method in class bitronix.tm.resource.jdbc.JdbcPreparedStatementHandle
 
hashCode() - Method in class bitronix.tm.resource.jdbc.lrc.LrcXAConnection
 
hashCode() - Method in class bitronix.tm.resource.jms.MessageProducerConsumerKey
 
hashCode() - Method in class bitronix.tm.utils.Uid
 
head() - Method in class bitronix.tm.journal.DiskForceWaitQueue
 

I

IncrementalRecoverer - class bitronix.tm.recovery.IncrementalRecoverer.
Incremental resource recoverer.
IncrementalRecoverer() - Constructor for class bitronix.tm.recovery.IncrementalRecoverer
 
InitializationException - exception bitronix.tm.utils.InitializationException.
Thrown at transaction manager startup when an error occurs.
InitializationException(String) - Constructor for class bitronix.tm.utils.InitializationException
 
InitializationException(String, Throwable) - Constructor for class bitronix.tm.utils.InitializationException
 
inPoolSize() - Method in class bitronix.tm.resource.common.XAPool
 
incCreatedResourcesCounter() - Method in class bitronix.tm.resource.common.ResourceBean
Increment a transient counter.
init() - Method in class bitronix.tm.resource.ResourceLoader
Initialize the ResourceLoader and load the resources configuration file specified in bitronix.tm.resource.configuration property.
init() - Method in interface bitronix.tm.resource.common.XAResourceProducer
Initialize this XAResourceProducer's internal resources.
init() - Method in class bitronix.tm.resource.ehcache.EhCacheXAResourceProducer
Initialize this XAResourceProducer's internal resources.
init() - Method in class bitronix.tm.resource.jdbc.PoolingDataSource
Initializes the pool by creating the initial amount of connections.
init() - Method in class bitronix.tm.resource.jms.JndiXAConnectionFactory
 
init() - Method in class bitronix.tm.resource.jms.PoolingConnectionFactory
Initialize the pool by creating the initial amount of connections.
intToBytes(int) - Static method in class bitronix.tm.utils.Encoder
 
invoke(Object, Method, Object[]) - Method in class bitronix.tm.resource.jdbc.BaseProxyHandlerClass
Implementation of the InvocationHandler interface.
isAsynchronous2Pc() - Method in class bitronix.tm.Configuration
Should two phase commit be executed asynchronously ?
isCellEditable(int, int) - Method in class bitronix.tm.gui.PendingTransactionTableModel
 
isCellEditable(int, int) - Method in class bitronix.tm.gui.RawTransactionTableModel
 
isClosed() - Method in class bitronix.tm.resource.jdbc.JdbcConnectionHandle
 
isClosed() - Method in class bitronix.tm.resource.jdbc.JdbcPreparedStatementHandle
 
isClosed() - Method in class bitronix.tm.resource.jdbc.lrc.LrcConnectionHandle
 
isCrc32Correct() - Method in class bitronix.tm.journal.TransactionLogRecord
Recalculate the CRC32 value of this record (using TransactionLogRecord.calculateCrc32()) and compare it with the stored value.
isCurrentNodeOnlyRecovery() - Method in class bitronix.tm.Configuration
Should the recovery process not recover XIDs generated with another JVM unique ID ?
isDisableJmx() - Method in class bitronix.tm.Configuration
Should JMX Mbeans not be registered even if a JMX MBean server is detected ?
isDone(Object) - Method in class bitronix.tm.twopc.executor.ConcurrentExecutor
 
isDone(Object) - Method in interface bitronix.tm.twopc.executor.Executor
Check if the thread pool has terminated the execution of the job represented by a future.
isDone(Object) - Method in class bitronix.tm.twopc.executor.SimpleAsyncExecutor
 
isDone(Object) - Method in class bitronix.tm.twopc.executor.SyncExecutor
 
isEmpty() - Method in class bitronix.tm.journal.DiskForceWaitQueue
 
isEnableJdbc4ConnectionTest() - Method in class bitronix.tm.resource.jdbc.PoolingDataSource
 
isEnded() - Method in class bitronix.tm.internal.XAResourceHolderState
 
isFilterLogStatus() - Method in class bitronix.tm.Configuration
Should only mandatory logs be written ?
isForceBatchingEnabled() - Method in class bitronix.tm.Configuration
Are disk forces batched ?
isForcedWriteEnabled() - Method in class bitronix.tm.Configuration
Are logs forced to disk ?
isLeaf(Object) - Method in class bitronix.tm.gui.ResourcesTreeModel
 
isNarrowJndiObject() - Method in class bitronix.tm.resource.jms.JndiXAConnectionFactory
Should PortableRemoteObject.narrow(Object, Class) be applied on the object looked up from JNDI before trying to cast it to XAConnectionFactory ?
isParticipating(XAResourceHolderState) - Method in class bitronix.tm.twopc.AbstractPhaseEngine
Determine if a resource is participating in the phase or not.
isParticipating(XAResourceHolderState) - Method in class bitronix.tm.twopc.Committer
 
isParticipating(XAResourceHolderState) - Method in class bitronix.tm.twopc.Preparer
 
isParticipating(XAResourceHolderState) - Method in class bitronix.tm.twopc.Rollbacker
 
isParticipatingInActiveGlobalTransaction() - Method in class bitronix.tm.resource.common.AbstractXAResourceHolder
If this method returns false, then local transaction calls like Connection.commit() can be made.
isRunning() - Method in class bitronix.tm.recovery.Recoverer
Check if the recoverer currently is running.
isRunning() - Method in interface bitronix.tm.recovery.RecovererMBean
 
isSameRM(XAResource) - Method in class bitronix.tm.resource.jdbc.lrc.LrcXAResource
 
isSameRM(XAResource) - Method in class bitronix.tm.resource.jms.lrc.LrcXAResource
 
isSkipCorruptedLogs() - Method in class bitronix.tm.Configuration
Should corrupted logs be skipped ?
isStarted() - Method in class bitronix.tm.internal.XAResourceHolderState
 
isSuspended() - Method in class bitronix.tm.internal.XAResourceHolderState
 
isTaskSchedulerRunning() - Static method in class bitronix.tm.TransactionManagerServices
Check if the task scheduler has started.
isTransactionManagerRunning() - Static method in class bitronix.tm.TransactionManagerServices
Check if the transaction manager has started.
isUnilateralRollback() - Method in class bitronix.tm.internal.BitronixMultiSystemException
 
isUnilateralRollback(XAException) - Static method in class bitronix.tm.internal.BitronixXAException
 
isUsable() - Method in class bitronix.tm.twopc.executor.ConcurrentExecutor
 
isUsable() - Method in interface bitronix.tm.twopc.executor.Executor
Check if the thread pool can be used.
isUsable() - Method in class bitronix.tm.twopc.executor.SimpleAsyncExecutor
 
isUsable() - Method in class bitronix.tm.twopc.executor.SyncExecutor
 
isWarnAboutZeroResourceTransaction() - Method in class bitronix.tm.Configuration
Should transactions executed without a single enlisted resource result in a warning or not ?
isWrapperFor(Class) - Method in class bitronix.tm.resource.jdbc.JdbcCallableStatementHandle
 
isWrapperFor(Class) - Method in class bitronix.tm.resource.jdbc.JdbcConnectionHandle
 
isWrapperFor(Class) - Method in class bitronix.tm.resource.jdbc.JdbcPreparedStatementHandle
 
isWrapperFor(Class) - Method in class bitronix.tm.resource.jdbc.JdbcStatementHandle
 
isWrapperFor(Class) - Method in class bitronix.tm.resource.jdbc.JdbcUncachedPreparedStatementHandle
 
isWrapperFor(Class) - Method in class bitronix.tm.resource.jdbc.PoolingDataSource
 
iterator() - Method in class bitronix.tm.utils.Scheduler
 

J

JdbcCallableStatementHandle - class bitronix.tm.resource.jdbc.JdbcCallableStatementHandle.
CallableStatement Statement wrapper.
JdbcCallableStatementHandle(CallableStatement, JdbcPooledConnection) - Constructor for class bitronix.tm.resource.jdbc.JdbcCallableStatementHandle
 
JdbcConnectionHandle - class bitronix.tm.resource.jdbc.JdbcConnectionHandle.
Disposable Connection handle.
JdbcConnectionHandle(JdbcPooledConnection, Connection) - Constructor for class bitronix.tm.resource.jdbc.JdbcConnectionHandle
 
JdbcPooledConnection - class bitronix.tm.resource.jdbc.JdbcPooledConnection.
Implementation of a JDBC pooled connection wrapping vendor's XAConnection implementation.
JdbcPooledConnection(PoolingDataSource, XAConnection) - Constructor for class bitronix.tm.resource.jdbc.JdbcPooledConnection
 
JdbcPooledConnectionMBean - interface bitronix.tm.resource.jdbc.JdbcPooledConnectionMBean.
JdbcPooledConnection Management interface.
JdbcPreparedStatementHandle - class bitronix.tm.resource.jdbc.JdbcPreparedStatementHandle.
Caching PreparedStatement wrapper.
JdbcPreparedStatementHandle(String) - Constructor for class bitronix.tm.resource.jdbc.JdbcPreparedStatementHandle
 
JdbcPreparedStatementHandle(String, int) - Constructor for class bitronix.tm.resource.jdbc.JdbcPreparedStatementHandle
 
JdbcPreparedStatementHandle(String, int, int) - Constructor for class bitronix.tm.resource.jdbc.JdbcPreparedStatementHandle
 
JdbcPreparedStatementHandle(String, int, int, int) - Constructor for class bitronix.tm.resource.jdbc.JdbcPreparedStatementHandle
 
JdbcPreparedStatementHandle(String, int[]) - Constructor for class bitronix.tm.resource.jdbc.JdbcPreparedStatementHandle
 
JdbcPreparedStatementHandle(String, String[]) - Constructor for class bitronix.tm.resource.jdbc.JdbcPreparedStatementHandle
 
JdbcStatementHandle - class bitronix.tm.resource.jdbc.JdbcStatementHandle.
Statement Statement wrapper.
JdbcStatementHandle(Statement, JdbcPooledConnection) - Constructor for class bitronix.tm.resource.jdbc.JdbcStatementHandle
 
JdbcUncachedPreparedStatementHandle - class bitronix.tm.resource.jdbc.JdbcUncachedPreparedStatementHandle.
 
JdbcUncachedPreparedStatementHandle(PreparedStatement, JdbcPooledConnection) - Constructor for class bitronix.tm.resource.jdbc.JdbcUncachedPreparedStatementHandle
 
JmsConnectionHandle - class bitronix.tm.resource.jms.JmsConnectionHandle.
Disposable Connection handle.
JmsConnectionHandle(JmsPooledConnection, XAConnection) - Constructor for class bitronix.tm.resource.jms.JmsConnectionHandle
 
JmsPooledConnection - class bitronix.tm.resource.jms.JmsPooledConnection.
Implementation of a JMS pooled connection wrapping vendor's XAConnection implementation.
JmsPooledConnection(PoolingConnectionFactory, XAConnection) - Constructor for class bitronix.tm.resource.jms.JmsPooledConnection
 
JmsPooledConnectionMBean - interface bitronix.tm.resource.jms.JmsPooledConnectionMBean.
JmsPooledConnection Management interface.
JndiXAConnectionFactory - class bitronix.tm.resource.jms.JndiXAConnectionFactory.
XAConnectionFactory implementation that wraps another XAConnectionFactory implementation available in some JNDI tree.
JndiXAConnectionFactory() - Constructor for class bitronix.tm.resource.jms.JndiXAConnectionFactory
 
Job - class bitronix.tm.twopc.executor.Job.
Abstract job definition executable by the 2PC thread pools.
Job(XAResourceHolderState) - Constructor for class bitronix.tm.twopc.executor.Job
 
Journal - interface bitronix.tm.journal.Journal.
Transaction logs journal implementations must implement this interface to provide functionality required by the transaction manager.

L

LrcConnectionHandle - class bitronix.tm.resource.jdbc.lrc.LrcConnectionHandle.
Connection handle implementation for a non-XA JDBC resource emulating XA with Last Resource Commit.
LrcConnectionHandle(LrcXAResource, Connection) - Constructor for class bitronix.tm.resource.jdbc.lrc.LrcConnectionHandle
 
LrcXAConnection - class bitronix.tm.resource.jdbc.lrc.LrcXAConnection.
XAConnection implementation for a non-XA JDBC resource emulating XA with Last Resource Commit.
LrcXAConnection(Connection) - Constructor for class bitronix.tm.resource.jdbc.lrc.LrcXAConnection
 
LrcXAConnection - class bitronix.tm.resource.jms.lrc.LrcXAConnection.
XAConnection implementation for a non-XA JMS resource emulating XA with Last Resource Commit.
LrcXAConnection(Connection) - Constructor for class bitronix.tm.resource.jms.lrc.LrcXAConnection
 
LrcXAConnectionFactory - class bitronix.tm.resource.jms.lrc.LrcXAConnectionFactory.
XAConnectionFactory implementation for a non-XA JMS resource emulating XA with Last Resource Commit.
LrcXAConnectionFactory() - Constructor for class bitronix.tm.resource.jms.lrc.LrcXAConnectionFactory
 
LrcXADataSource - class bitronix.tm.resource.jdbc.lrc.LrcXADataSource.
XADataSource implementation for a non-XA JDBC resource emulating XA with Last Resource Commit.
LrcXADataSource() - Constructor for class bitronix.tm.resource.jdbc.lrc.LrcXADataSource
 
LrcXAResource - class bitronix.tm.resource.jdbc.lrc.LrcXAResource.
XAResource implementation for a non-XA JDBC connection emulating XA with Last Resource Commit.
LrcXAResource(Connection) - Constructor for class bitronix.tm.resource.jdbc.lrc.LrcXAResource
 
LrcXAResource - class bitronix.tm.resource.jms.lrc.LrcXAResource.
XAResource implementation for a non-XA JMS connection emulating XA with Last Resource Commit.
LrcXAResource(Session) - Constructor for class bitronix.tm.resource.jms.lrc.LrcXAResource
 
LrcXASession - class bitronix.tm.resource.jms.lrc.LrcXASession.
XASession implementation for a non-XA JMS resource emulating XA with Last Resource Commit.
LrcXASession(Session) - Constructor for class bitronix.tm.resource.jms.lrc.LrcXASession
 
LruEvictionListener - interface bitronix.tm.resource.jdbc.LruEvictionListener.
Eviction listener interface for LruStatementCache.
LruStatementCache - class bitronix.tm.resource.jdbc.LruStatementCache.
Last Recently Used PreparedStatement cache with eviction listeners support implementation.
LruStatementCache(int) - Constructor for class bitronix.tm.resource.jdbc.LruStatementCache
 
list(Name) - Method in class bitronix.tm.jndi.BitronixContext
 
list(String) - Method in class bitronix.tm.jndi.BitronixContext
 
listBindings(Name) - Method in class bitronix.tm.jndi.BitronixContext
 
listBindings(String) - Method in class bitronix.tm.jndi.BitronixContext
 
loadClass(String) - Static method in class bitronix.tm.utils.ClassLoaderUtils
Load a class by name.
log(int, Uid, Set) - Method in class bitronix.tm.journal.DiskJournal
Log a new transaction status to journal.
log(int, Uid, Set) - Method in interface bitronix.tm.journal.Journal
Log a new transaction status to journal.
log(int, Uid, Set) - Method in class bitronix.tm.journal.NullJournal
 
logFailedResources(PhaseException) - Method in class bitronix.tm.twopc.AbstractPhaseEngine
Log exceptions that happened during a phase failure.
longToBytes(long) - Static method in class bitronix.tm.utils.Encoder
 
lookup(Name) - Method in class bitronix.tm.jndi.BitronixContext
 
lookup(String) - Method in class bitronix.tm.jndi.BitronixContext
 
lookupLink(Name) - Method in class bitronix.tm.jndi.BitronixContext
 
lookupLink(String) - Method in class bitronix.tm.jndi.BitronixContext
 

M

ManagementRegistrar - class bitronix.tm.utils.ManagementRegistrar.
Simple JMX facade.
ManagementRegistrar() - Constructor for class bitronix.tm.utils.ManagementRegistrar
 
MessageConsumerWrapper - class bitronix.tm.resource.jms.MessageConsumerWrapper.
MessageConsumer wrapper that adds XA enlistment semantics.
MessageConsumerWrapper(MessageConsumer, DualSessionWrapper, PoolingConnectionFactory) - Constructor for class bitronix.tm.resource.jms.MessageConsumerWrapper
 
MessageProducerConsumerKey - class bitronix.tm.resource.jms.MessageProducerConsumerKey.
JMS destination wrapper optimized for use with hashed collections where it is the key and a MessageProducer or a MessageConsumer is the value.
MessageProducerConsumerKey(Destination) - Constructor for class bitronix.tm.resource.jms.MessageProducerConsumerKey
 
MessageProducerConsumerKey(Destination, String) - Constructor for class bitronix.tm.resource.jms.MessageProducerConsumerKey
 
MessageProducerConsumerKey(Destination, String, boolean) - Constructor for class bitronix.tm.resource.jms.MessageProducerConsumerKey
 
MessageProducerWrapper - class bitronix.tm.resource.jms.MessageProducerWrapper.
MessageProducer wrapper that adds XA enlistment semantics.
MessageProducerWrapper(MessageProducer, DualSessionWrapper, PoolingConnectionFactory) - Constructor for class bitronix.tm.resource.jms.MessageProducerWrapper
 
main(String[]) - Static method in class bitronix.tm.gui.Console
 
main(String[]) - Static method in class bitronix.tm.utils.CryptoEngine
Main method of this class to be used as a command-line tool to get a crypted version of a resource password.
makeValidName(String) - Static method in class bitronix.tm.utils.ManagementRegistrar
Replace characters considered illegal in a management object's name.
mouseClicked(MouseEvent) - Method in class bitronix.tm.gui.TransactionTableMouseListener
 

N

NO_TX - Static variable in class bitronix.tm.resource.jdbc.lrc.LrcXAResource
 
NO_TX - Static variable in class bitronix.tm.resource.jms.lrc.LrcXAResource
 
NullJournal - class bitronix.tm.journal.NullJournal.
No-op journal.
NullJournal() - Constructor for class bitronix.tm.journal.NullJournal
 

O

onEviction(Object) - Method in interface bitronix.tm.resource.jdbc.LruEvictionListener
 
open() - Method in class bitronix.tm.journal.DiskJournal
Open the disk journal.
open() - Method in interface bitronix.tm.journal.Journal
Open the journal.
open() - Method in class bitronix.tm.journal.NullJournal
 

P

PREPARED - Static variable in class bitronix.tm.resource.jdbc.lrc.LrcXAResource
 
PREPARED - Static variable in class bitronix.tm.resource.jms.lrc.LrcXAResource
 
PendingTransactionTableModel - class bitronix.tm.gui.PendingTransactionTableModel.
© Bitronix Software
PendingTransactionTableModel(File) - Constructor for class bitronix.tm.gui.PendingTransactionTableModel
 
PhaseException - exception bitronix.tm.twopc.PhaseException.
Thrown when a phase exection has thrown one or more exception(s).
PhaseException(List, List) - Constructor for class bitronix.tm.twopc.PhaseException
 
PoolShrinkingTask - class bitronix.tm.timer.PoolShrinkingTask.
This task is used to notify a XA pool to close idle connections.
PoolShrinkingTask(XAPool, Date, TaskScheduler) - Constructor for class bitronix.tm.timer.PoolShrinkingTask
 
PoolingConnectionFactory - class bitronix.tm.resource.jms.PoolingConnectionFactory.
Implementation of a JMS ConnectionFactory wrapping vendor's XAConnectionFactory implementation.
PoolingConnectionFactory() - Constructor for class bitronix.tm.resource.jms.PoolingConnectionFactory
 
PoolingConnectionFactoryMBean - interface bitronix.tm.resource.jms.PoolingConnectionFactoryMBean.
© Bitronix Software
PoolingDataSource - class bitronix.tm.resource.jdbc.PoolingDataSource.
Implementation of a JDBC DataSource wrapping vendor's XADataSource implementation.
PoolingDataSource() - Constructor for class bitronix.tm.resource.jdbc.PoolingDataSource
 
PoolingDataSourceMBean - interface bitronix.tm.resource.jdbc.PoolingDataSourceMBean.
© Bitronix Software
Preparer - class bitronix.tm.twopc.Preparer.
Phase 1 Prepare logic engine.
Preparer(Executor) - Constructor for class bitronix.tm.twopc.Preparer
 
PropertyException - exception bitronix.tm.utils.PropertyException.
Thrown by PropertyUtils when some reflection error occurs.
PropertyException(String, Throwable) - Constructor for class bitronix.tm.utils.PropertyException
 
PropertyException(String) - Constructor for class bitronix.tm.utils.PropertyException
 
PropertyUtils - class bitronix.tm.utils.PropertyUtils.
Smart reflection helper.
PropertyUtils() - Constructor for class bitronix.tm.utils.PropertyUtils
 
pickCurrentLogFile(File, File) - Static method in class bitronix.tm.gui.Console
 
prepare(Xid) - Method in class bitronix.tm.resource.jdbc.lrc.LrcXAResource
 
prepare(Xid) - Method in class bitronix.tm.resource.jms.lrc.LrcXAResource
 
prepare(BitronixTransaction) - Method in class bitronix.tm.twopc.Preparer
Execute phase 1 prepare.
prepareCall(String) - Method in class bitronix.tm.resource.jdbc.JdbcConnectionHandle
 
prepareCall(String, int, int) - Method in class bitronix.tm.resource.jdbc.JdbcConnectionHandle
 
prepareCall(String, int, int, int) - Method in class bitronix.tm.resource.jdbc.JdbcConnectionHandle
 
prepareStatement(String) - Method in class bitronix.tm.resource.jdbc.JdbcConnectionHandle
 
prepareStatement(String, int) - Method in class bitronix.tm.resource.jdbc.JdbcConnectionHandle
 
prepareStatement(String, int, int) - Method in class bitronix.tm.resource.jdbc.JdbcConnectionHandle
 
prepareStatement(String, int, int, int) - Method in class bitronix.tm.resource.jdbc.JdbcConnectionHandle
 
prepareStatement(String, int[]) - Method in class bitronix.tm.resource.jdbc.JdbcConnectionHandle
 
prepareStatement(String, String[]) - Method in class bitronix.tm.resource.jdbc.JdbcConnectionHandle
 
propertiesToString(Object) - Static method in class bitronix.tm.utils.PropertyUtils
Return a comma-separated String of r/w properties of the specified object.
put(JdbcPreparedStatementHandle) - Method in class bitronix.tm.resource.jdbc.LruStatementCache
A statement is put into the cache.
putCachedStatement(JdbcPreparedStatementHandle) - Method in class bitronix.tm.resource.jdbc.JdbcPooledConnection
Put a PreparedStatement in the cache.
putResource(Object, Object) - Method in class bitronix.tm.BitronixTransactionSynchronizationRegistry
 
putXAResourceHolderState(BitronixXid, XAResourceHolderState) - Method in class bitronix.tm.resource.common.AbstractXAResourceHolder
 
putXAResourceHolderState(BitronixXid, XAResourceHolderState) - Method in interface bitronix.tm.resource.common.XAResourceHolder
Add a XAResourceHolderState of this wrapped resource.

R

RawTransactionTableModel - class bitronix.tm.gui.RawTransactionTableModel.
© Bitronix Software
RawTransactionTableModel(File) - Constructor for class bitronix.tm.gui.RawTransactionTableModel
 
Recoverer - class bitronix.tm.recovery.Recoverer.
Recovery process implementation.
Recoverer() - Constructor for class bitronix.tm.recovery.Recoverer
 
RecovererMBean - interface bitronix.tm.recovery.RecovererMBean.
Recoverer Management interface.
RecoveryException - exception bitronix.tm.recovery.RecoveryException.
Thrown when an error occurs during recovery.
RecoveryException(String, Throwable) - Constructor for class bitronix.tm.recovery.RecoveryException
 
RecoveryException(String) - Constructor for class bitronix.tm.recovery.RecoveryException
 
RecoveryHelper - class bitronix.tm.recovery.RecoveryHelper.
Reovery helper methods.
RecoveryHelper() - Constructor for class bitronix.tm.recovery.RecoveryHelper
 
RecoveryTask - class bitronix.tm.timer.RecoveryTask.
This task is used to run the background recovery.
RecoveryTask(Recoverer, Date, TaskScheduler) - Constructor for class bitronix.tm.timer.RecoveryTask
 
RecoveryXAResourceHolder - class bitronix.tm.resource.common.RecoveryXAResourceHolder.
XAResourceHolder created by an XAResourceProducer that is used to perform recovery.
RecoveryXAResourceHolder(XAResourceHolder) - Constructor for class bitronix.tm.resource.common.RecoveryXAResourceHolder
 
ResourceBean - class bitronix.tm.resource.common.ResourceBean.
Abstract javabean container for all common properties of a XAResourceProducer as configured in the resources configuration file.
ResourceBean() - Constructor for class bitronix.tm.resource.common.ResourceBean
Initialize all properties with their default values.
ResourceConfigurationException - exception bitronix.tm.resource.ResourceConfigurationException.
Thrown when a resource cannot be created due to a configuration error.
ResourceConfigurationException(String, Throwable) - Constructor for class bitronix.tm.resource.ResourceConfigurationException
 
ResourceConfigurationException(String) - Constructor for class bitronix.tm.resource.ResourceConfigurationException
 
ResourceLoader - class bitronix.tm.resource.ResourceLoader.
XA resources pools configurator & loader.
ResourceLoader() - Constructor for class bitronix.tm.resource.ResourceLoader
 
ResourceObjectFactory - class bitronix.tm.resource.ResourceObjectFactory.
XAResourceProducer object factory for JNDI references.
ResourceObjectFactory() - Constructor for class bitronix.tm.resource.ResourceObjectFactory
 
ResourceRegistrar - class bitronix.tm.resource.ResourceRegistrar.
Collection of initialized XAResourceProducers.
ResourceRegistrar() - Constructor for class bitronix.tm.resource.ResourceRegistrar
 
ResourcesPanel - class bitronix.tm.gui.ResourcesPanel.
© Bitronix Software
ResourcesPanel() - Constructor for class bitronix.tm.gui.ResourcesPanel
 
ResourcesTreeModel - class bitronix.tm.gui.ResourcesTreeModel.
© Bitronix Software
ResourcesTreeModel() - Constructor for class bitronix.tm.gui.ResourcesTreeModel
 
Rollbacker - class bitronix.tm.twopc.Rollbacker.
Phase 1 & 2 Rollback logic engine.
Rollbacker(Executor) - Constructor for class bitronix.tm.twopc.Rollbacker
 
read(File, boolean) - Method in class bitronix.tm.gui.TransactionLogHeaderPanel
 
readFullTransactionLog(File) - Method in class bitronix.tm.gui.PendingTransactionTableModel
 
readFullTransactionLog(File) - Method in class bitronix.tm.gui.TransactionTableModel
 
readLog() - Method in class bitronix.tm.journal.TransactionLogCursor
Fetch the next TransactionLogRecord from log, recalculating the CRC and checking it against the stored one.
readLog(boolean) - Method in class bitronix.tm.journal.TransactionLogCursor
Fetch the next TransactionLogRecord from log.
rebind(Name, Object) - Method in class bitronix.tm.jndi.BitronixContext
 
rebind(String, Object) - Method in class bitronix.tm.jndi.BitronixContext
 
receive() - Method in class bitronix.tm.resource.jms.MessageConsumerWrapper
 
receive(long) - Method in class bitronix.tm.resource.jms.MessageConsumerWrapper
 
receiveNoWait() - Method in class bitronix.tm.resource.jms.MessageConsumerWrapper
 
recover(XAResourceProducer) - Static method in class bitronix.tm.recovery.IncrementalRecoverer
Run incremental recovery on the specified resource.
recover(XAResourceHolderState) - Static method in class bitronix.tm.recovery.RecoveryHelper
Run the recovery process on the target resource.
recover(int) - Method in class bitronix.tm.resource.jdbc.lrc.LrcXAResource
 
recover() - Method in class bitronix.tm.resource.jms.DualSessionWrapper
 
recover(int) - Method in class bitronix.tm.resource.jms.lrc.LrcXAResource
 
recover() - Method in class bitronix.tm.resource.jms.lrc.LrcXASession
 
recycle(XAStatefulHolder) - Static method in class bitronix.tm.resource.common.TransactionContextHelper
Ensure the XAStatefulHolder's release won't be deferred anymore (when appropriate) as it has been recycled.
register(XAResourceProducer) - Static method in class bitronix.tm.resource.ResourceRegistrar
Register a XAResourceProducer.
register(String, Object) - Static method in class bitronix.tm.utils.ManagementRegistrar
Register the specified management object.
registerInterposedSynchronization(Synchronization) - Method in class bitronix.tm.BitronixTransactionSynchronizationRegistry
 
registerSynchronization(Synchronization) - Method in class bitronix.tm.BitronixTransaction
 
registerUncachedStatement(Statement) - Method in class bitronix.tm.resource.jdbc.JdbcPooledConnection
Register uncached statement so that it can be closed when the connection is put back in the pool.
registerXAResource(String, XAResource) - Static method in class bitronix.tm.resource.ehcache.EhCacheXAResourceProducer
Register an XAResource of a cache with BTM.
release() - Method in class bitronix.tm.resource.jdbc.JdbcPooledConnection
 
release() - Method in class bitronix.tm.resource.jms.JmsPooledConnection
 
releaseSavepoint(Savepoint) - Method in class bitronix.tm.resource.jdbc.JdbcConnectionHandle
 
remove(Object) - Method in class bitronix.tm.utils.Scheduler
 
removeConnectionEventListener(ConnectionEventListener) - Method in class bitronix.tm.resource.jdbc.lrc.LrcXAConnection
 
removeEvictionListener(LruEvictionListener) - Method in class bitronix.tm.resource.jdbc.LruStatementCache
 
removeFromEnvironment(String) - Method in class bitronix.tm.jndi.BitronixContext
 
removeStateChangeEventListener(StateChangeListener) - Method in class bitronix.tm.resource.common.AbstractXAStatefulHolder
 
removeStateChangeEventListener(StateChangeListener) - Method in interface bitronix.tm.resource.common.XAStatefulHolder
Unregister an implementation of StateChangeListener.
removeTableModelListener(TableModelListener) - Method in class bitronix.tm.gui.PendingTransactionTableModel
 
removeTableModelListener(TableModelListener) - Method in class bitronix.tm.gui.RawTransactionTableModel
 
removeTreeModelListener(TreeModelListener) - Method in class bitronix.tm.gui.ResourcesTreeModel
 
removeUniqueNames(Collection) - Method in class bitronix.tm.journal.TransactionLogRecord
 
removeXAResourceHolderState(BitronixXid) - Method in class bitronix.tm.resource.common.AbstractXAResourceHolder
 
removeXAResourceHolderState(BitronixXid) - Method in interface bitronix.tm.resource.common.XAResourceHolder
Remove all states related to a specific Xid from this wrapped resource.
rename(Name, Name) - Method in class bitronix.tm.jndi.BitronixContext
 
rename(String, String) - Method in class bitronix.tm.jndi.BitronixContext
 
requeue(XAStatefulHolder, ResourceBean) - Static method in class bitronix.tm.resource.common.TransactionContextHelper
Switch the XAStatefulHolder's state appropriately after the acquired resource handle has been closed.
reset() - Method in class bitronix.tm.resource.common.XAPool
 
reset() - Method in class bitronix.tm.resource.jdbc.PoolingDataSource
 
reset() - Method in interface bitronix.tm.resource.jdbc.PoolingDataSourceMBean
 
reset() - Method in class bitronix.tm.resource.jms.PoolingConnectionFactory
 
reset() - Method in interface bitronix.tm.resource.jms.PoolingConnectionFactoryMBean
 
resume(Transaction) - Method in class bitronix.tm.BitronixTransactionManager
 
resume() - Method in class bitronix.tm.internal.XAResourceManager
Resume all enlisted resources in the current transaction context.
reverseIterator() - Method in class bitronix.tm.utils.Scheduler
 
rewind() - Method in class bitronix.tm.journal.TransactionLogHeader
Rewind CURRENT_POSITION_HEADER back to the beginning of the file.
rollback() - Method in class bitronix.tm.BitronixTransaction
 
rollback() - Method in class bitronix.tm.BitronixTransactionManager
 
rollback(XAResourceHolderState, Xid) - Static method in class bitronix.tm.recovery.RecoveryHelper
Rollback the specified branch of a dangling transaction.
rollback() - Method in class bitronix.tm.resource.jdbc.JdbcConnectionHandle
 
rollback(Savepoint) - Method in class bitronix.tm.resource.jdbc.JdbcConnectionHandle
 
rollback() - Method in class bitronix.tm.resource.jdbc.lrc.LrcConnectionHandle
 
rollback(Savepoint) - Method in class bitronix.tm.resource.jdbc.lrc.LrcConnectionHandle
 
rollback(Xid) - Method in class bitronix.tm.resource.jdbc.lrc.LrcXAResource
 
rollback() - Method in class bitronix.tm.resource.jms.DualSessionWrapper
 
rollback(Xid) - Method in class bitronix.tm.resource.jms.lrc.LrcXAResource
 
rollback() - Method in class bitronix.tm.resource.jms.lrc.LrcXASession
 
rollback(BitronixTransaction, List) - Method in class bitronix.tm.twopc.Rollbacker
Rollback the current XA transaction.
run() - Method in class bitronix.tm.journal.DiskForceBatcherThread
 
run() - Method in class bitronix.tm.recovery.Recoverer
Run the recovery process.
run() - Method in interface bitronix.tm.recovery.RecovererMBean
 
run() - Method in class bitronix.tm.resource.jms.DualSessionWrapper
 
run() - Method in class bitronix.tm.resource.jms.lrc.LrcXASession
 
run() - Method in class bitronix.tm.timer.TaskScheduler
 
run() - Method in class bitronix.tm.twopc.executor.Job
 
runtimeException - Variable in class bitronix.tm.twopc.executor.Job
 

S

STARTED - Static variable in class bitronix.tm.resource.jdbc.lrc.LrcXAResource
 
STARTED - Static variable in class bitronix.tm.resource.jms.lrc.LrcXAResource
 
STATE_ACCESSIBLE - Static variable in interface bitronix.tm.resource.common.XAStatefulHolder
The state in which the resource is when it out of the pool but accessible by the application.
STATE_CLOSED - Static variable in interface bitronix.tm.resource.common.XAStatefulHolder
The state in which the resource is when it is closed and unusable.
STATE_HEADER - Static variable in class bitronix.tm.journal.TransactionLogHeader
Position of the log file state in the header.
STATE_IN_POOL - Static variable in interface bitronix.tm.resource.common.XAStatefulHolder
The state in which the resource is when it is available in the pool.
STATE_NOT_ACCESSIBLE - Static variable in interface bitronix.tm.resource.common.XAStatefulHolder
The state in which the resource is when it out of the pool but not accessible by the application.
Scheduler - class bitronix.tm.utils.Scheduler.
Positional object container.
Scheduler() - Constructor for class bitronix.tm.utils.Scheduler
 
Service - interface bitronix.tm.utils.Service.
All internal services implement this interface.
SimpleAsyncExecutor - class bitronix.tm.twopc.executor.SimpleAsyncExecutor.
This implementation spawns a new thread per request.
SimpleAsyncExecutor() - Constructor for class bitronix.tm.twopc.executor.SimpleAsyncExecutor
 
StateChangeListener - interface bitronix.tm.resource.common.StateChangeListener.
XAStatefulHolder state change listener interface.
SyncExecutor - class bitronix.tm.twopc.executor.SyncExecutor.
This implementation executes submitted jobs synchronously.
SyncExecutor() - Constructor for class bitronix.tm.twopc.executor.SyncExecutor
 
schedulePoolShrinking(XAPool) - Method in class bitronix.tm.timer.TaskScheduler
Schedule a task that will tell a XA pool to close idle connections.
scheduleRecovery(Recoverer, Date) - Method in class bitronix.tm.timer.TaskScheduler
Schedule a task that will run background recovery at the specified date.
scheduleTransactionTimeout(BitronixTransaction, Date) - Method in class bitronix.tm.timer.TaskScheduler
Schedule a task that will mark the transaction as timed out at the specified date.
send(Message) - Method in class bitronix.tm.resource.jms.MessageProducerWrapper
 
send(Message, int, int, long) - Method in class bitronix.tm.resource.jms.MessageProducerWrapper
 
send(Destination, Message) - Method in class bitronix.tm.resource.jms.MessageProducerWrapper
 
send(Destination, Message, int, int, long) - Method in class bitronix.tm.resource.jms.MessageProducerWrapper
 
session - Variable in class bitronix.tm.resource.jms.MessageConsumerWrapper
 
session - Variable in class bitronix.tm.resource.jms.MessageProducerWrapper
 
setAcquireIncrement(int) - Method in class bitronix.tm.resource.common.ResourceBean
Define the amount of connections to be created at once when the pool needs to grow.
setAcquisitionInterval(int) - Method in class bitronix.tm.resource.common.ResourceBean
Set the amount of time in seconds the pool will wait before trying to acquire a connection again after an invalid connection has been attempted to be acquired.
setAcquisitionTimeout(int) - Method in class bitronix.tm.resource.common.ResourceBean
Define the amount of time in seconds a call to get a connection from the pool will wait when the pool is empty.
setActive(int) - Method in class bitronix.tm.BitronixTransaction
 
setAlive(boolean) - Method in class bitronix.tm.journal.DiskForceBatcherThread
Thread will run for as long as this flag is not false.
setAllowLocalTransactions(boolean) - Method in class bitronix.tm.resource.common.ResourceBean
Set if the transaction manager should allow mixing XA and non-XA transactions.
setApplyTransactionTimeout(boolean) - Method in class bitronix.tm.resource.common.ResourceBean
Set if the transaction-timeout should be set on the XAResource when the XAResource is enlisted.
setAsynchronous2Pc(boolean) - Method in class bitronix.tm.Configuration
Set if two phase commit should be executed asynchronously.
setAutoCommit(boolean) - Method in class bitronix.tm.resource.jdbc.JdbcConnectionHandle
 
setAutoCommit(boolean) - Method in class bitronix.tm.resource.jdbc.lrc.LrcConnectionHandle
 
setAutomaticEnlistingEnabled(boolean) - Method in class bitronix.tm.resource.common.ResourceBean
Specify if the XA resource wrapper should enlist/delist this resource automatically in global transactions.
setBackgroundRecoveryInterval(int) - Method in class bitronix.tm.Configuration
Deprecated. superceded by #setBackgroundRecoveryIntervalSeconds(int).
setBackgroundRecoveryIntervalSeconds(int) - Method in class bitronix.tm.Configuration
Set the interval in seconds at which to run the recovery process in the background.
setCacheProducersConsumers(boolean) - Method in class bitronix.tm.resource.jms.PoolingConnectionFactory
 
setClassName(String) - Method in class bitronix.tm.resource.common.ResourceBean
Specify the underlying implementation class name of the XA resource described by this bean.
setClientID(String) - Method in class bitronix.tm.resource.jms.JmsConnectionHandle
 
setClientID(String) - Method in class bitronix.tm.resource.jms.lrc.LrcXAConnection
 
setConnectionFactoryClassName(String) - Method in class bitronix.tm.resource.jms.lrc.LrcXAConnectionFactory
 
setCurrentNodeOnlyRecovery(boolean) - Method in class bitronix.tm.Configuration
Set to true if recovery should filter out recovered XIDs that do not contain this JVM's unique ID, false otherwise.
setCursorHoldability(String) - Method in class bitronix.tm.resource.jdbc.PoolingDataSource
Set the default cursor holdability for connections.
setDefaultTransactionTimeout(int) - Method in class bitronix.tm.Configuration
Set the default transaction timeout in seconds.
setDeferConnectionRelease(boolean) - Method in class bitronix.tm.resource.common.ResourceBean
Define the transaction interleaving capability of the database.
setDelegate(PreparedStatement) - Method in class bitronix.tm.resource.jdbc.JdbcPreparedStatementHandle
 
setDeliveryMode(int) - Method in class bitronix.tm.resource.jms.MessageProducerWrapper
 
setDisableJmx(boolean) - Method in class bitronix.tm.Configuration
Set to true if JMX Mbeans should not be registered even if a JMX MBean server is detected.
setDisableMessageID(boolean) - Method in class bitronix.tm.resource.jms.MessageProducerWrapper
 
setDisableMessageTimestamp(boolean) - Method in class bitronix.tm.resource.jms.MessageProducerWrapper
 
setDriverClassName(String) - Method in class bitronix.tm.resource.jdbc.lrc.LrcXADataSource
 
setDriverProperties(Properties) - Method in class bitronix.tm.resource.common.ResourceBean
Set the properties that should be set on the underlying implementation.
setEnableJdbc4ConnectionTest(boolean) - Method in class bitronix.tm.resource.jdbc.PoolingDataSource
When set and the underlying JDBC driver supports JDBC 4 isValid(), a Connection.isValid() call is performed to test the connection before handing it to the caller.
setExceptionListener(ExceptionListener) - Method in class bitronix.tm.resource.jms.JmsConnectionHandle
 
setExceptionListener(ExceptionListener) - Method in class bitronix.tm.resource.jms.lrc.LrcXAConnection
 
setExecutionTime(Date) - Method in class bitronix.tm.timer.Task
 
setExtraJndiProperties(Properties) - Method in class bitronix.tm.resource.jms.JndiXAConnectionFactory
Set the extra JNDI environment properties added the the InitialContext's environment upon creation.
setFailed(boolean) - Method in class bitronix.tm.resource.common.XAPool
 
setFailed(boolean) - Method in interface bitronix.tm.resource.common.XAResourceProducer
Mark this resource producer as failed or not.
setFailed(boolean) - Method in class bitronix.tm.resource.ehcache.EhCacheXAResourceProducer
Mark this resource producer as failed or not. A resource is considered failed if recovery fails to run on it.
setFailed(boolean) - Method in class bitronix.tm.resource.jdbc.PoolingDataSource
 
setFailed(boolean) - Method in class bitronix.tm.resource.jms.PoolingConnectionFactory
 
setFilterLogStatus(boolean) - Method in class bitronix.tm.Configuration
Set if only mandatory logs should be written.
setForceBatchingEnabled(boolean) - Method in class bitronix.tm.Configuration
Set if disk forces are batched.
setForcedWriteEnabled(boolean) - Method in class bitronix.tm.Configuration
Set if logs are forced to disk.
setFormatId(int) - Method in class bitronix.tm.journal.TransactionLogHeader
Set FORMAT_ID_HEADER.
setFuture(Object) - Method in class bitronix.tm.twopc.executor.Job
 
setGracefulShutdownInterval(int) - Method in class bitronix.tm.Configuration
Set the maximum amount of seconds the TM will wait for transactions to get done before aborting them at shutdown time.
setInitialContextFactory(String) - Method in class bitronix.tm.resource.jms.JndiXAConnectionFactory
Set the Context.INITIAL_CONTEXT_FACTORY of the JNDI Context used to fetch the XAConnectionFactory.
setIsolationLevel(String) - Method in class bitronix.tm.resource.jdbc.PoolingDataSource
Set the default isolation level for connections.
setJndiTransactionSynchronizationRegistryName(String) - Method in class bitronix.tm.Configuration
Set the name the TransactionSynchronizationRegistry should be bound under in the BitronixContext.
setJndiUserTransactionName(String) - Method in class bitronix.tm.Configuration
Set the name the UserTransaction should be bound under in the BitronixContext.
setJournal(String) - Method in class bitronix.tm.Configuration
Set the journal name.
setLocalAutoCommit(String) - Method in class bitronix.tm.resource.jdbc.PoolingDataSource
Set the default local transactions autocommit mode.
setLogFile(File) - Method in class bitronix.tm.gui.TransactionLogHeaderPanel
 
setLogPart1Filename(String) - Method in class bitronix.tm.Configuration
Set the journal fragment file 1 name.
setLogPart2Filename(String) - Method in class bitronix.tm.Configuration
Set the journal fragment file 2 name.
setLogWriter(PrintWriter) - Method in class bitronix.tm.resource.jdbc.PoolingDataSource
 
setLogWriter(PrintWriter) - Method in class bitronix.tm.resource.jdbc.lrc.LrcXADataSource
 
setLoginTimeout(int) - Method in class bitronix.tm.resource.jdbc.PoolingDataSource
 
setLoginTimeout(int) - Method in class bitronix.tm.resource.jdbc.lrc.LrcXADataSource
 
setMaxIdleTime(int) - Method in class bitronix.tm.resource.common.ResourceBean
Define the amount of seconds and idle connection can stay in the pool before getting closed.
setMaxLogSizeInMb(int) - Method in class bitronix.tm.Configuration
Set the Maximum size in megabytes of the journal fragments.
setMaxPoolSize(int) - Method in class bitronix.tm.resource.common.ResourceBean
Define the maximum amount of connections that can be in the pool.
setMessageListener(MessageListener) - Method in class bitronix.tm.resource.jms.DualSessionWrapper
 
setMessageListener(MessageListener) - Method in class bitronix.tm.resource.jms.MessageConsumerWrapper
 
setMessageListener(MessageListener) - Method in class bitronix.tm.resource.jms.lrc.LrcXASession
 
setMinPoolSize(int) - Method in class bitronix.tm.resource.common.ResourceBean
Define the minimal amount of connections that can be in the pool.
setName(String) - Method in class bitronix.tm.resource.jms.JndiXAConnectionFactory
Set the JNDI name under which the XAConnectionFactory is available.
setNarrowJndiObject(boolean) - Method in class bitronix.tm.resource.jms.JndiXAConnectionFactory
Set if PortableRemoteObject.narrow(Object, Class) should be applied on the object looked up from JNDI before trying to cast it to XAConnectionFactory ?
setPassword(String) - Method in class bitronix.tm.resource.jdbc.lrc.LrcXADataSource
 
setPassword(String) - Method in class bitronix.tm.resource.jms.PoolingConnectionFactory
 
setPooledConnection(JdbcPooledConnection) - Method in class bitronix.tm.resource.jdbc.JdbcPreparedStatementHandle
Set the parent connection that created this statement.
setPosition(long) - Method in class bitronix.tm.gui.TransactionLogHeaderPanel
 
setPosition(long) - Method in class bitronix.tm.journal.TransactionLogHeader
Set CURRENT_POSITION_HEADER.
setPreparedStatementCacheSize(int) - Method in class bitronix.tm.resource.jdbc.PoolingDataSource
Set the target maximum size of the prepared statement cache.
setPriority(int) - Method in class bitronix.tm.resource.jms.MessageProducerWrapper
 
setProperties(Properties) - Method in class bitronix.tm.resource.jms.lrc.LrcXAConnectionFactory
 
setProperties(Object, Map) - Static method in class bitronix.tm.utils.PropertyUtils
Set a Map of direct or indirect properties on the target object.
setProperty(Object, String, Object) - Static method in class bitronix.tm.utils.PropertyUtils
Set a direct or indirect property (dotted property: prop1.prop2.prop3) on the target object.
setProviderUrl(String) - Method in class bitronix.tm.resource.jms.JndiXAConnectionFactory
Set the Context.PROVIDER_URL of the JNDI Context used to fetch the XAConnectionFactory.
setResourceConfigurationFilename(String) - Method in class bitronix.tm.Configuration
Set the ResourceLoader configuration file name.
setRollbackOnly() - Method in class bitronix.tm.BitronixTransaction
 
setRollbackOnly() - Method in class bitronix.tm.BitronixTransactionManager
 
setRollbackOnly() - Method in class bitronix.tm.BitronixTransactionSynchronizationRegistry
 
setSavepoint() - Method in class bitronix.tm.resource.jdbc.JdbcConnectionHandle
 
setSavepoint(String) - Method in class bitronix.tm.resource.jdbc.JdbcConnectionHandle
 
setSecurityCredentials(String) - Method in class bitronix.tm.resource.jms.JndiXAConnectionFactory
Set the Context.SECURITY_CREDENTIALS of the JNDI Context used to fetch the XAConnectionFactory.
setSecurityPrincipal(String) - Method in class bitronix.tm.resource.jms.JndiXAConnectionFactory
Set the Context.SECURITY_PRINCIPAL of the JNDI Context used to fetch the XAConnectionFactory.
setServerId(String) - Method in class bitronix.tm.Configuration
Set the ASCII ID that must uniquely identify this TM instance.
setShareTransactionConnections(boolean) - Method in class bitronix.tm.resource.common.ResourceBean
Set whether connections in the ACCESSIBLE state can be shared within the context of a transaction.
setSkipCorruptedLogs(boolean) - Method in class bitronix.tm.Configuration
Set if corrupted logs should be skipped.
setState(byte) - Method in class bitronix.tm.gui.TransactionLogHeaderPanel
 
setState(byte) - Method in class bitronix.tm.journal.TransactionLogHeader
Set STATE_HEADER.
setState(int) - Method in class bitronix.tm.resource.common.AbstractXAStatefulHolder
 
setState(int) - Method in interface bitronix.tm.resource.common.XAStatefulHolder
Set the current resource state.
setStatus(int) - Method in class bitronix.tm.BitronixTransaction
 
setStatus(int, Set) - Method in class bitronix.tm.BitronixTransaction
 
setTestConnections(boolean) - Method in class bitronix.tm.resource.jms.PoolingConnectionFactory
 
setTestQuery(String) - Method in class bitronix.tm.resource.jdbc.PoolingDataSource
When set, the specified query will be executed on the connection acquired from the pool before being handed to the caller.
setTimeToLive(long) - Method in class bitronix.tm.resource.jms.MessageProducerWrapper
 
setTimeout(int) - Method in class bitronix.tm.internal.ThreadContext
Set this context's default timeout.
setTimestamp(long) - Method in class bitronix.tm.gui.TransactionLogHeaderPanel
 
setTimestamp(long) - Method in class bitronix.tm.journal.TransactionLogHeader
Set TIMESTAMP_HEADER.
setTransaction(BitronixTransaction) - Method in class bitronix.tm.internal.ThreadContext
Link a transaction with this thead context.
setTransactionTimeout(int) - Method in class bitronix.tm.BitronixTransactionManager
 
setTransactionTimeout(int) - Method in class bitronix.tm.resource.jdbc.lrc.LrcXAResource
 
setTransactionTimeout(int) - Method in class bitronix.tm.resource.jms.lrc.LrcXAResource
 
setTransactionTimeoutDate(Date) - Method in class bitronix.tm.internal.XAResourceHolderState
 
setTwoPcOrderingPosition(int) - Method in class bitronix.tm.resource.common.ResourceBean
Set the position at which this resource should stand during 2PC commit.
setUniqueName(String) - Method in class bitronix.tm.resource.common.ResourceBean
Specify the resource unique name to be used to identify this resource during recovery.
setUrl(String) - Method in class bitronix.tm.resource.jdbc.lrc.LrcXADataSource
 
setUrlPkgPrefixes(String) - Method in class bitronix.tm.resource.jms.JndiXAConnectionFactory
Set the Context.URL_PKG_PREFIXES of the JNDI Context used to fetch the XAConnectionFactory.
setUseTmJoin(boolean) - Method in class bitronix.tm.resource.common.ResourceBean
Specify if the transaction manager should try to join resources by calling XAResource.start(javax.transaction.xa.Xid, int) with XAResource.TMJOIN.
setUser(String) - Method in class bitronix.tm.resource.jdbc.lrc.LrcXADataSource
 
setUser(String) - Method in class bitronix.tm.resource.jms.PoolingConnectionFactory
 
setValueAt(Object, int, int) - Method in class bitronix.tm.gui.PendingTransactionTableModel
 
setValueAt(Object, int, int) - Method in class bitronix.tm.gui.RawTransactionTableModel
 
setWarnAboutZeroResourceTransaction(boolean) - Method in class bitronix.tm.Configuration
Set if transactions executed without a single enlisted resource should result in a warning or not.
setXid(BitronixXid) - Method in class bitronix.tm.internal.XAResourceHolderState
 
shortToBytes(short) - Static method in class bitronix.tm.utils.Encoder
 
shrink() - Method in class bitronix.tm.resource.common.XAPool
 
shutdown() - Method in class bitronix.tm.BitronixTransactionManager
Shut down the transaction manager and release all resources held by it.
shutdown() - Method in class bitronix.tm.Configuration
 
shutdown() - Method in class bitronix.tm.journal.DiskJournal
 
shutdown() - Method in class bitronix.tm.journal.NullJournal
 
shutdown() - Method in class bitronix.tm.recovery.Recoverer
 
shutdown() - Method in class bitronix.tm.resource.ResourceLoader
 
shutdown() - Method in class bitronix.tm.timer.TaskScheduler
 
shutdown() - Method in class bitronix.tm.twopc.executor.ConcurrentExecutor
 
shutdown() - Method in interface bitronix.tm.twopc.executor.Executor
Shutdown the thead pool.
shutdown() - Method in class bitronix.tm.twopc.executor.SimpleAsyncExecutor
 
shutdown() - Method in class bitronix.tm.twopc.executor.SyncExecutor
 
shutdown() - Method in interface bitronix.tm.utils.Service
Shutdown the service and free all held resources.
size() - Method in class bitronix.tm.internal.XAResourceManager
Get the enlisted resources count.
size() - Method in class bitronix.tm.journal.DiskForceWaitQueue
 
size() - Method in class bitronix.tm.utils.Scheduler
 
start(int) - Method in class bitronix.tm.internal.XAResourceHolderState
 
start(Xid, int) - Method in class bitronix.tm.resource.jdbc.lrc.LrcXAResource
 
start() - Method in class bitronix.tm.resource.jms.JmsConnectionHandle
 
start() - Method in class bitronix.tm.resource.jms.lrc.LrcXAConnection
 
start(Xid, int) - Method in class bitronix.tm.resource.jms.lrc.LrcXAResource
 
startRecovery() - Method in interface bitronix.tm.resource.common.XAResourceProducer
Prepare the recoverable XAResource producer for recovery.
startRecovery() - Method in class bitronix.tm.resource.ehcache.EhCacheXAResourceProducer
Prepare the recoverable XAResource producer for recovery.
startRecovery() - Method in class bitronix.tm.resource.jdbc.PoolingDataSource
 
startRecovery() - Method in class bitronix.tm.resource.jms.PoolingConnectionFactory
 
stateChanged(XAStatefulHolder, int, int) - Method in interface bitronix.tm.resource.common.StateChangeListener
Fired when the internal state of a XAStatefulHolder has changed.
stateChanged(XAStatefulHolder, int, int) - Method in class bitronix.tm.resource.common.XAPool
 
stateChanged(XAStatefulHolder, int, int) - Method in class bitronix.tm.resource.jdbc.JdbcPooledConnection
 
stateChanged(XAStatefulHolder, int, int) - Method in class bitronix.tm.resource.jms.DualSessionWrapper
 
stateChanging(XAStatefulHolder, int, int) - Method in interface bitronix.tm.resource.common.StateChangeListener
Fired before the internal state of a XAStatefulHolder has changed.
stateChanging(XAStatefulHolder, int, int) - Method in class bitronix.tm.resource.common.XAPool
 
stateChanging(XAStatefulHolder, int, int) - Method in class bitronix.tm.resource.jdbc.JdbcPooledConnection
 
stateChanging(XAStatefulHolder, int, int) - Method in class bitronix.tm.resource.jms.DualSessionWrapper
 
statusChanged(int, int) - Method in interface bitronix.tm.internal.TransactionStatusChangeListener
Fired when the status of a BitronixTransaction has changed.
stop() - Method in class bitronix.tm.resource.jms.JmsConnectionHandle
 
stop() - Method in class bitronix.tm.resource.jms.lrc.LrcXAConnection
 
submit(Job) - Method in class bitronix.tm.twopc.executor.ConcurrentExecutor
 
submit(Job) - Method in interface bitronix.tm.twopc.executor.Executor
Submit a job to be executed by the thread pool.
submit(Job) - Method in class bitronix.tm.twopc.executor.SimpleAsyncExecutor
 
submit(Job) - Method in class bitronix.tm.twopc.executor.SyncExecutor
 
suspend() - Method in class bitronix.tm.BitronixTransactionManager
 
suspend() - Method in class bitronix.tm.internal.XAResourceManager
Suspend all enlisted resources from the current transaction context.

T

TIMESTAMP_HEADER - Static variable in class bitronix.tm.journal.TransactionLogHeader
Position of the timestamp in the header.
Task - class bitronix.tm.timer.Task.
Asbtract superclass of all timed tasks.
Task(Date, TaskScheduler) - Constructor for class bitronix.tm.timer.Task
 
TaskException - exception bitronix.tm.timer.TaskException.
Thrown when an error occurs during the execution of a task.
TaskException(String, Throwable) - Constructor for class bitronix.tm.timer.TaskException
 
TaskScheduler - class bitronix.tm.timer.TaskScheduler.
Timed tasks service.
TaskScheduler() - Constructor for class bitronix.tm.timer.TaskScheduler
 
ThreadContext - class bitronix.tm.internal.ThreadContext.
Transactional context of a thread.
ThreadContext() - Constructor for class bitronix.tm.internal.ThreadContext
 
TopicSubscriberWrapper - class bitronix.tm.resource.jms.TopicSubscriberWrapper.
TopicSubscriber wrapper that adds XA enlistment semantics.
TopicSubscriberWrapper(TopicSubscriber, DualSessionWrapper, PoolingConnectionFactory) - Constructor for class bitronix.tm.resource.jms.TopicSubscriberWrapper
 
TransactionContextHelper - class bitronix.tm.resource.common.TransactionContextHelper.
Helper class that contains static logic common accross all resource types.
TransactionContextHelper() - Constructor for class bitronix.tm.resource.common.TransactionContextHelper
 
TransactionLogAppender - class bitronix.tm.journal.TransactionLogAppender.
Used to write TransactionLogRecord objects to a log file.
TransactionLogAppender(File, long) - Constructor for class bitronix.tm.journal.TransactionLogAppender
Create an appender that will write to specified file up to the specified maximum length.
TransactionLogCursor - class bitronix.tm.journal.TransactionLogCursor.
Used to read TransactionLogRecord objects from a log file.
TransactionLogCursor(File) - Constructor for class bitronix.tm.journal.TransactionLogCursor
Create a TransactionLogCursor that will read from the specified file.
TransactionLogDialog - class bitronix.tm.gui.TransactionLogDialog.
© Bitronix Software
TransactionLogDialog(JFrame, TransactionLogRecord) - Constructor for class bitronix.tm.gui.TransactionLogDialog
 
TransactionLogHeader - class bitronix.tm.journal.TransactionLogHeader.
Used to control a log file's header.
TransactionLogHeader(RandomAccessFile, long) - Constructor for class bitronix.tm.journal.TransactionLogHeader
TransactionLogHeader are used to control headers of the specified RandomAccessFile.
TransactionLogHeaderPanel - class bitronix.tm.gui.TransactionLogHeaderPanel.
© Bitronix Software
TransactionLogHeaderPanel() - Constructor for class bitronix.tm.gui.TransactionLogHeaderPanel
 
TransactionLogRecord - class bitronix.tm.journal.TransactionLogRecord.
Representation of a transaction log record on disk.
TransactionLogRecord(int, int, int, long, int, int, Uid, Set, int) - Constructor for class bitronix.tm.journal.TransactionLogRecord
Use this constructor when restoring a log from the disk.
TransactionLogRecord(int, Uid, Set) - Constructor for class bitronix.tm.journal.TransactionLogRecord
Create a new transaction log ready to be stored.
TransactionManagerServices - class bitronix.tm.TransactionManagerServices.
Container for all BTM services.
TransactionManagerServices() - Constructor for class bitronix.tm.TransactionManagerServices
 
TransactionStatusChangeListener - interface bitronix.tm.internal.TransactionStatusChangeListener.
BitronixTransaction status change listener interface.
TransactionTableCellRenderer - class bitronix.tm.gui.TransactionTableCellRenderer.
© Bitronix Software
TransactionTableCellRenderer() - Constructor for class bitronix.tm.gui.TransactionTableCellRenderer
 
TransactionTableModel - class bitronix.tm.gui.TransactionTableModel.
© Bitronix Software
TransactionTableModel() - Constructor for class bitronix.tm.gui.TransactionTableModel
 
TransactionTableMouseListener - class bitronix.tm.gui.TransactionTableMouseListener.
© Bitronix Software
TransactionTableMouseListener(JFrame, JTable) - Constructor for class bitronix.tm.gui.TransactionTableMouseListener
 
TransactionTimeoutException - exception bitronix.tm.internal.TransactionTimeoutException.
Thrown when a transaction times out.
TransactionTimeoutException(String) - Constructor for class bitronix.tm.internal.TransactionTimeoutException
 
TransactionTimeoutException(String, Throwable) - Constructor for class bitronix.tm.internal.TransactionTimeoutException
 
TransactionTimeoutTask - class bitronix.tm.timer.TransactionTimeoutTask.
This task is used to mark a transaction as timed-out.
TransactionTimeoutTask(BitronixTransaction, Date, TaskScheduler) - Constructor for class bitronix.tm.timer.TransactionTimeoutTask
 
tLogs - Variable in class bitronix.tm.gui.TransactionTableModel
 
timedOut() - Method in class bitronix.tm.BitronixTransaction
 
timeout() - Method in class bitronix.tm.BitronixTransaction
 
toString() - Method in class bitronix.tm.BitronixTransaction
 
toString() - Method in class bitronix.tm.BitronixTransactionManager
 
toString() - Method in class bitronix.tm.BitronixXid
Get a human-readable string representation of the XID.
toString() - Method in class bitronix.tm.Configuration
 
toString() - Method in class bitronix.tm.internal.ThreadContext
Return a human-readable representation.
toString() - Method in class bitronix.tm.internal.XAResourceHolderState
 
toString() - Method in class bitronix.tm.internal.XAResourceManager
Return a human-readable representation of this object.
toString() - Method in class bitronix.tm.jndi.BitronixContext
 
toString() - Method in class bitronix.tm.jndi.BitronixInitialContextFactory
 
toString() - Method in class bitronix.tm.journal.DiskForceBatcherThread
 
toString() - Method in class bitronix.tm.journal.NullJournal
 
toString() - Method in class bitronix.tm.journal.TransactionLogAppender
 
toString() - Method in class bitronix.tm.journal.TransactionLogHeader
Create human-readable String representation.
toString() - Method in class bitronix.tm.journal.TransactionLogRecord
 
toString() - Method in class bitronix.tm.resource.common.DeferredReleaseSynchronization
 
toString() - Method in class bitronix.tm.resource.common.XAPool
 
toString() - Method in class bitronix.tm.resource.jdbc.JdbcConnectionHandle
 
toString() - Method in class bitronix.tm.resource.jdbc.JdbcPooledConnection
 
toString() - Method in class bitronix.tm.resource.jdbc.JdbcPreparedStatementHandle
 
toString() - Method in class bitronix.tm.resource.jdbc.PoolingDataSource
 
toString() - Method in class bitronix.tm.resource.jdbc.lrc.LrcConnectionHandle
 
toString() - Method in class bitronix.tm.resource.jdbc.lrc.LrcXAConnection
 
toString() - Method in class bitronix.tm.resource.jdbc.lrc.LrcXADataSource
 
toString() - Method in class bitronix.tm.resource.jdbc.lrc.LrcXAResource
 
toString() - Method in class bitronix.tm.resource.jms.DualSessionWrapper
 
toString() - Method in class bitronix.tm.resource.jms.JmsConnectionHandle
 
toString() - Method in class bitronix.tm.resource.jms.JmsPooledConnection
 
toString() - Method in class bitronix.tm.resource.jms.MessageConsumerWrapper
 
toString() - Method in class bitronix.tm.resource.jms.MessageProducerConsumerKey
 
toString() - Method in class bitronix.tm.resource.jms.MessageProducerWrapper
 
toString() - Method in class bitronix.tm.resource.jms.PoolingConnectionFactory
 
toString() - Method in class bitronix.tm.resource.jms.TopicSubscriberWrapper
 
toString() - Method in class bitronix.tm.resource.jms.lrc.LrcXAConnection
 
toString() - Method in class bitronix.tm.resource.jms.lrc.LrcXAConnectionFactory
 
toString() - Method in class bitronix.tm.resource.jms.lrc.LrcXAResource
 
toString() - Method in class bitronix.tm.resource.jms.lrc.LrcXASession
 
toString() - Method in class bitronix.tm.timer.PoolShrinkingTask
 
toString() - Method in class bitronix.tm.timer.RecoveryTask
 
toString() - Method in class bitronix.tm.timer.TransactionTimeoutTask
 
toString() - Method in class bitronix.tm.utils.Scheduler
 
toString() - Method in class bitronix.tm.utils.Uid
 
totalPoolSize() - Method in class bitronix.tm.resource.common.XAPool
 

U

UNCLEAN_LOG_STATE - Static variable in class bitronix.tm.journal.TransactionLogHeader
State of the log file when it hasn't been closed properly or it is still open.
Uid - class bitronix.tm.utils.Uid.
A constant UID byte array container optimized for use with hashed collections.
Uid(byte[]) - Constructor for class bitronix.tm.utils.Uid
 
UidGenerator - class bitronix.tm.utils.UidGenerator.
Helper that offers UID generation (GTRID, XID, sequences) needed by the transaction manager.
UidGenerator() - Constructor for class bitronix.tm.utils.UidGenerator
 
unbind(Name) - Method in class bitronix.tm.jndi.BitronixContext
 
unbind(String) - Method in class bitronix.tm.jndi.BitronixContext
 
unregister(XAResourceProducer) - Static method in class bitronix.tm.resource.ResourceRegistrar
Unregister a previously registered XAResourceProducer.
unregister(String) - Static method in class bitronix.tm.utils.ManagementRegistrar
Unregister the management object with the specified name.
unregisterUncachedStatement(Statement) - Method in class bitronix.tm.resource.jdbc.JdbcPooledConnection
 
unregisterXAResource(String, XAResource) - Static method in class bitronix.tm.resource.ehcache.EhCacheXAResourceProducer
Unregister an XAResource of a cache from BTM.
unsubscribe(String) - Method in class bitronix.tm.resource.jms.DualSessionWrapper
 
unsubscribe(String) - Method in class bitronix.tm.resource.jms.lrc.LrcXASession
 
unwrap(Class) - Method in class bitronix.tm.resource.jdbc.JdbcCallableStatementHandle
 
unwrap(Class) - Method in class bitronix.tm.resource.jdbc.JdbcConnectionHandle
 
unwrap(Class) - Method in class bitronix.tm.resource.jdbc.JdbcPreparedStatementHandle
 
unwrap(Class) - Method in class bitronix.tm.resource.jdbc.JdbcStatementHandle
 
unwrap(Class) - Method in class bitronix.tm.resource.jdbc.JdbcUncachedPreparedStatementHandle
 
unwrap(Class) - Method in class bitronix.tm.resource.jdbc.PoolingDataSource
 

V

valueForPathChanged(TreePath, Object) - Method in class bitronix.tm.gui.ResourcesTreeModel
 

W

waitFor(Object, long) - Method in class bitronix.tm.twopc.executor.ConcurrentExecutor
 
waitFor(Object, long) - Method in interface bitronix.tm.twopc.executor.Executor
Wait for the job represented by the future to terminate.
waitFor(Object, long) - Method in class bitronix.tm.twopc.executor.SimpleAsyncExecutor
 
waitFor(Object, long) - Method in class bitronix.tm.twopc.executor.SyncExecutor
 
waitUntilNotContains(TransactionLogAppender) - Method in class bitronix.tm.journal.DiskForceWaitQueue
 
waitUntilNotEmpty() - Method in class bitronix.tm.journal.DiskForceWaitQueue
 
writeLog(TransactionLogRecord) - Method in class bitronix.tm.journal.TransactionLogAppender
Write a TransactionLogRecord to disk.

X

XAPool - class bitronix.tm.resource.common.XAPool.
Generic XA pool.
XAPool(XAResourceProducer, ResourceBean) - Constructor for class bitronix.tm.resource.common.XAPool
 
XAResourceHolder - interface bitronix.tm.resource.common.XAResourceHolder.
XAResource wrappers must implement this interface.
XAResourceHolderState - class bitronix.tm.internal.XAResourceHolderState.
XAResourceHolder state container.
XAResourceHolderState(XAResourceHolder, ResourceBean) - Constructor for class bitronix.tm.internal.XAResourceHolderState
 
XAResourceHolderState(XAResourceHolderState) - Constructor for class bitronix.tm.internal.XAResourceHolderState
 
XAResourceManager - class bitronix.tm.internal.XAResourceManager.
Every BitronixTransaction contains an instance of this class that is used to register and keep track of resources enlisted in a transaction.
XAResourceManager(Uid) - Constructor for class bitronix.tm.internal.XAResourceManager
Create a resource manager for the specified GTRID.
XAResourceProducer - interface bitronix.tm.resource.common.XAResourceProducer.
A XAResourceProducer is a XAStatefulHolder factory.
XAStatefulHolder - interface bitronix.tm.resource.common.XAStatefulHolder.
Any pooled connection class must implement the XAStatefulHolder interface.
xaException - Variable in class bitronix.tm.twopc.executor.Job
 

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