Uses of Class
org.infinispan.transaction.xa.GlobalTransaction
-
-
Uses of GlobalTransaction in org.infinispan.commands
Methods in org.infinispan.commands with parameters of type GlobalTransaction Modifier and Type Method Description org.infinispan.commands.remote.ClusteredGetAllCommand
CommandsFactory. buildClusteredGetAllCommand(List<?> keys, long flagsBitSet, GlobalTransaction gtx)
Builds a ClusteredGetAllCommand, which is a remote lookup commandorg.infinispan.commands.remote.ClusteredGetAllCommand
CommandsFactoryImpl. buildClusteredGetAllCommand(List<?> keys, long flagsBitSet, GlobalTransaction gtx)
org.infinispan.commands.tx.CommitCommand
CommandsFactory. buildCommitCommand(GlobalTransaction gtx)
Builds a CommitCommandorg.infinispan.commands.tx.CommitCommand
CommandsFactoryImpl. buildCommitCommand(GlobalTransaction gtx)
org.infinispan.commands.control.LockControlCommand
CommandsFactory. buildLockControlCommand(Object key, long flagsBitSet, GlobalTransaction gtx)
Same asCommandsFactory.buildLockControlCommand(Object, long, GlobalTransaction)
but for locking a single key vs a collection of keys.org.infinispan.commands.control.LockControlCommand
CommandsFactory. buildLockControlCommand(Collection<?> keys, long flagsBitSet, GlobalTransaction gtx)
Builds a LockControlCommand to control explicit remote lockingorg.infinispan.commands.control.LockControlCommand
CommandsFactoryImpl. buildLockControlCommand(Object key, long flagsBitSet, GlobalTransaction gtx)
org.infinispan.commands.control.LockControlCommand
CommandsFactoryImpl. buildLockControlCommand(Collection<?> keys, long flagsBitSet, GlobalTransaction gtx)
org.infinispan.commands.tx.PrepareCommand
CommandsFactory. buildPrepareCommand(GlobalTransaction gtx, List<org.infinispan.commands.write.WriteCommand> modifications, boolean onePhaseCommit)
Builds a PrepareCommandorg.infinispan.commands.tx.PrepareCommand
CommandsFactoryImpl. buildPrepareCommand(GlobalTransaction gtx, List<org.infinispan.commands.write.WriteCommand> modifications, boolean onePhaseCommit)
org.infinispan.commands.tx.RollbackCommand
CommandsFactory. buildRollbackCommand(GlobalTransaction gtx)
Builds a RollbackCommandorg.infinispan.commands.tx.RollbackCommand
CommandsFactoryImpl. buildRollbackCommand(GlobalTransaction gtx)
org.infinispan.commands.remote.recovery.TxCompletionNotificationCommand
CommandsFactory. buildTxCompletionNotificationCommand(Xid xid, GlobalTransaction globalTransaction)
Builds aTxCompletionNotificationCommand
.org.infinispan.commands.remote.recovery.TxCompletionNotificationCommand
CommandsFactoryImpl. buildTxCompletionNotificationCommand(Xid xid, GlobalTransaction globalTransaction)
org.infinispan.commands.tx.VersionedCommitCommand
CommandsFactory. buildVersionedCommitCommand(GlobalTransaction gtx)
Builds a VersionedCommitCommandorg.infinispan.commands.tx.VersionedCommitCommand
CommandsFactoryImpl. buildVersionedCommitCommand(GlobalTransaction gtx)
org.infinispan.commands.tx.VersionedPrepareCommand
CommandsFactory. buildVersionedPrepareCommand(GlobalTransaction gtx, List<org.infinispan.commands.write.WriteCommand> modifications, boolean onePhase)
Builds a VersionedPrepareCommandorg.infinispan.commands.tx.VersionedPrepareCommand
CommandsFactoryImpl. buildVersionedPrepareCommand(GlobalTransaction gtx, List<org.infinispan.commands.write.WriteCommand> modifications, boolean onePhase)
-
Uses of GlobalTransaction in org.infinispan.context.impl
Methods in org.infinispan.context.impl that return GlobalTransaction Modifier and Type Method Description GlobalTransaction
AbstractTxInvocationContext. getGlobalTransaction()
GlobalTransaction
TxInvocationContext. getGlobalTransaction()
Returns the id of the transaction associated with the current call. -
Uses of GlobalTransaction in org.infinispan.interceptors.xsite
Methods in org.infinispan.interceptors.xsite with parameters of type GlobalTransaction Modifier and Type Method Description protected boolean
BaseBackupInterceptor. isTxFromRemoteSite(GlobalTransaction gtx)
-
Uses of GlobalTransaction in org.infinispan.notifications.cachelistener
Methods in org.infinispan.notifications.cachelistener with parameters of type GlobalTransaction Modifier and Type Method Description void
CacheNotifier. notifyTransactionCompleted(GlobalTransaction transaction, boolean successful, InvocationContext ctx)
Notifies all registered listeners of a transaction completion event.void
CacheNotifierImpl. notifyTransactionCompleted(GlobalTransaction transaction, boolean successful, InvocationContext ctx)
void
CacheNotifier. notifyTransactionRegistered(GlobalTransaction globalTransaction, boolean isOriginLocal)
Notifies all registered listeners of a transaction registration event.void
CacheNotifierImpl. notifyTransactionRegistered(GlobalTransaction globalTransaction, boolean isOriginLocal)
-
Uses of GlobalTransaction in org.infinispan.notifications.cachelistener.cluster
Methods in org.infinispan.notifications.cachelistener.cluster that return GlobalTransaction Modifier and Type Method Description GlobalTransaction
ClusterEvent. getGlobalTransaction()
-
Uses of GlobalTransaction in org.infinispan.notifications.cachelistener.event
Methods in org.infinispan.notifications.cachelistener.event that return GlobalTransaction Modifier and Type Method Description GlobalTransaction
TransactionalEvent. getGlobalTransaction()
-
Uses of GlobalTransaction in org.infinispan.notifications.cachelistener.event.impl
Methods in org.infinispan.notifications.cachelistener.event.impl that return GlobalTransaction Modifier and Type Method Description GlobalTransaction
EventImpl. getGlobalTransaction()
Methods in org.infinispan.notifications.cachelistener.event.impl with parameters of type GlobalTransaction Modifier and Type Method Description void
EventImpl. setTransactionId(GlobalTransaction transaction)
-
Uses of GlobalTransaction in org.infinispan.partitionhandling.impl
Methods in org.infinispan.partitionhandling.impl that return types with arguments of type GlobalTransaction Modifier and Type Method Description Collection<GlobalTransaction>
AvailablePartitionHandlingManager. getPartialTransactions()
Collection<GlobalTransaction>
PartitionHandlingManager. getPartialTransactions()
Collection<GlobalTransaction>
PartitionHandlingManagerImpl. getPartialTransactions()
Methods in org.infinispan.partitionhandling.impl with parameters of type GlobalTransaction Modifier and Type Method Description boolean
AvailablePartitionHandlingManager. addPartialCommit1PCTransaction(GlobalTransaction globalTransaction, Collection<Address> affectedNodes, Collection<Object> lockedKeys, List<org.infinispan.commands.write.WriteCommand> modifications)
boolean
PartitionHandlingManager. addPartialCommit1PCTransaction(GlobalTransaction globalTransaction, Collection<Address> affectedNodes, Collection<Object> lockedKeys, List<org.infinispan.commands.write.WriteCommand> modifications)
Adds a partially committed transaction.boolean
PartitionHandlingManagerImpl. addPartialCommit1PCTransaction(GlobalTransaction globalTransaction, Collection<Address> affectedNodes, Collection<Object> lockedKeys, List<org.infinispan.commands.write.WriteCommand> modifications)
boolean
AvailablePartitionHandlingManager. addPartialCommit2PCTransaction(GlobalTransaction globalTransaction, Collection<Address> affectedNodes, Collection<Object> lockedKeys, EntryVersionsMap newVersions)
boolean
PartitionHandlingManager. addPartialCommit2PCTransaction(GlobalTransaction globalTransaction, Collection<Address> affectedNodes, Collection<Object> lockedKeys, EntryVersionsMap newVersions)
Adds a partially committed transaction.boolean
PartitionHandlingManagerImpl. addPartialCommit2PCTransaction(GlobalTransaction globalTransaction, Collection<Address> affectedNodes, Collection<Object> lockedKeys, EntryVersionsMap newVersions)
boolean
AvailablePartitionHandlingManager. addPartialRollbackTransaction(GlobalTransaction globalTransaction, Collection<Address> affectedNodes, Collection<Object> lockedKeys)
boolean
PartitionHandlingManager. addPartialRollbackTransaction(GlobalTransaction globalTransaction, Collection<Address> affectedNodes, Collection<Object> lockedKeys)
Adds a partially aborted transaction.boolean
PartitionHandlingManagerImpl. addPartialRollbackTransaction(GlobalTransaction globalTransaction, Collection<Address> affectedNodes, Collection<Object> lockedKeys)
boolean
AvailablePartitionHandlingManager. canRollbackTransactionAfterOriginatorLeave(GlobalTransaction globalTransaction)
boolean
PartitionHandlingManager. canRollbackTransactionAfterOriginatorLeave(GlobalTransaction globalTransaction)
It checks if the transaction can be aborted when the originator leaves the cluster.boolean
PartitionHandlingManagerImpl. canRollbackTransactionAfterOriginatorLeave(GlobalTransaction globalTransaction)
boolean
AvailablePartitionHandlingManager. isTransactionPartiallyCommitted(GlobalTransaction globalTransaction)
boolean
PartitionHandlingManager. isTransactionPartiallyCommitted(GlobalTransaction globalTransaction)
It checks if the transaction resources (for example locks) can be released.boolean
PartitionHandlingManagerImpl. isTransactionPartiallyCommitted(GlobalTransaction globalTransaction)
-
Uses of GlobalTransaction in org.infinispan.query.backend
Constructor parameters in org.infinispan.query.backend with type arguments of type GlobalTransaction Constructor Description QueryInterceptor(org.hibernate.search.spi.SearchIntegrator searchFactory, KeyTransformationHandler keyTransformationHandler, IndexModificationStrategy indexingMode, ConcurrentMap<GlobalTransaction,Map<Object,Object>> txOldValues, AdvancedCache<?,?> cache)
TxQueryInterceptor(ConcurrentMap<GlobalTransaction,Map<Object,Object>> txOldValues, QueryInterceptor queryInterceptor)
-
Uses of GlobalTransaction in org.infinispan.server.hotrod.tx
Methods in org.infinispan.server.hotrod.tx with parameters of type GlobalTransaction Modifier and Type Method Description boolean
ServerTransactionOriginatorChecker. isOriginatorMissing(GlobalTransaction gtx)
boolean
ServerTransactionOriginatorChecker. isOriginatorMissing(GlobalTransaction gtx, Collection<Address> liveMembers)
int
PrepareCoordinator. onePhaseCommitRemoteTransaction(GlobalTransaction gtx, List<org.infinispan.commands.write.WriteCommand> modifications)
Commits a remote 1PC transaction that is already in MARK_COMMIT statevoid
PrepareCoordinator. rollbackRemoteTransaction(GlobalTransaction gtx)
Rollbacks a transaction that is remove in all the cluster members. -
Uses of GlobalTransaction in org.infinispan.server.hotrod.tx.table
Methods in org.infinispan.server.hotrod.tx.table that return GlobalTransaction Modifier and Type Method Description GlobalTransaction
TxState. getGlobalTransaction()
Constructors in org.infinispan.server.hotrod.tx.table with parameters of type GlobalTransaction Constructor Description TxState(GlobalTransaction globalTransaction, boolean recoverable, long timeout, org.infinispan.commons.time.TimeService timeService)
-
Uses of GlobalTransaction in org.infinispan.server.hotrod.tx.table.functions
Constructors in org.infinispan.server.hotrod.tx.table.functions with parameters of type GlobalTransaction Constructor Description CreateStateFunction(GlobalTransaction globalTransaction, boolean recoverable, long timeout)
-
Uses of GlobalTransaction in org.infinispan.statetransfer
Methods in org.infinispan.statetransfer that return GlobalTransaction Modifier and Type Method Description GlobalTransaction
TransactionInfo. getGlobalTransaction()
Constructors in org.infinispan.statetransfer with parameters of type GlobalTransaction Constructor Description TransactionInfo(GlobalTransaction globalTransaction, int topologyId, org.infinispan.commands.write.WriteCommand[] modifications, Set<Object> lockedKeys)
-
Uses of GlobalTransaction in org.infinispan.stats
Methods in org.infinispan.stats with parameters of type GlobalTransaction Modifier and Type Method Description void
CacheStatisticManager. add(ExtendedStatistic stat, double value, GlobalTransaction globalTransaction, boolean local)
Adds a value to a statistic.void
CacheStatisticManager. beginTransaction(GlobalTransaction globalTransaction, boolean local)
Signals the start of a transaction.void
CacheStatisticManager. increment(ExtendedStatistic stat, GlobalTransaction globalTransaction, boolean local)
Increments the statistic value.void
CacheStatisticManager. markAsWriteTransaction(GlobalTransaction globalTransaction, boolean local)
Marks the transaction as a write transaction (instead of a read only transaction)void
CacheStatisticManager. onPrepareCommand(GlobalTransaction globalTransaction, boolean local)
Invoked when aPrepareCommand
is received for a transaction.void
CacheStatisticManager. setTransactionOutcome(boolean commit, GlobalTransaction globalTransaction, boolean local)
Sets the transaction outcome to commit or rollback, depending if the transaction has commit successfully or not respectively.void
CacheStatisticManager. terminateTransaction(GlobalTransaction globalTransaction, boolean local, boolean remote)
Signals the ending of a transaction. -
Uses of GlobalTransaction in org.infinispan.transaction
Methods in org.infinispan.transaction that return GlobalTransaction Modifier and Type Method Description GlobalTransaction
TransactionTable. getGlobalTransaction(Transaction transaction)
Methods in org.infinispan.transaction that return types with arguments of type GlobalTransaction Modifier and Type Method Description Collection<GlobalTransaction>
TransactionTable. getLocalGlobalTransaction()
Collection<GlobalTransaction>
TransactionTable. getRemoteGlobalTransaction()
-
Uses of GlobalTransaction in org.infinispan.transaction.impl
Fields in org.infinispan.transaction.impl declared as GlobalTransaction Modifier and Type Field Description protected GlobalTransaction
AbstractCacheTransaction. tx
Methods in org.infinispan.transaction.impl that return GlobalTransaction Modifier and Type Method Description GlobalTransaction
AbstractCacheTransaction. getGlobalTransaction()
GlobalTransaction
TotalOrderRemoteTransactionState. getGlobalTransaction()
GlobalTransaction
TransactionTable. getGlobalTransaction(Transaction transaction)
Methods in org.infinispan.transaction.impl that return types with arguments of type GlobalTransaction Modifier and Type Method Description Collection<GlobalTransaction>
TransactionTable. getLocalGlobalTransaction()
Collection<GlobalTransaction>
TransactionTable. getRemoteGlobalTransaction()
Methods in org.infinispan.transaction.impl with parameters of type GlobalTransaction Modifier and Type Method Description boolean
TransactionTable. containRemoteTx(GlobalTransaction globalTransaction)
boolean
TransactionTable. containsLocalTx(GlobalTransaction globalTransaction)
TransactionTable.CompletedTransactionStatus
TransactionTable. getCompletedTransactionStatus(GlobalTransaction gtx)
LocalTransaction
TransactionTable. getLocalTransaction(GlobalTransaction txId)
Looks up a LocalTransaction given a GlobalTransaction.RemoteTransaction
TransactionTable. getOrCreateRemoteTransaction(GlobalTransaction globalTx, org.infinispan.commands.write.WriteCommand[] modifications)
Returns an existing remote transaction or creates one if none exists.RemoteTransaction
TransactionTable. getRemoteTransaction(GlobalTransaction txId)
Returns theRemoteTransaction
associated with the supplied transaction id.boolean
ClusteredTransactionOriginatorChecker. isOriginatorMissing(GlobalTransaction gtx)
boolean
ClusteredTransactionOriginatorChecker. isOriginatorMissing(GlobalTransaction gtx, Collection<Address> liveMembers)
boolean
TransactionOriginatorChecker. isOriginatorMissing(GlobalTransaction gtx)
boolean
TransactionOriginatorChecker. isOriginatorMissing(GlobalTransaction gtx, Collection<Address> liveMembers)
boolean
TransactionTable. isTransactionCompleted(GlobalTransaction gtx)
void
TransactionTable. markTransactionCompleted(GlobalTransaction gtx, boolean successful)
With the current state transfer implementation it is possible for a transaction to be prepared several times on a remote node.void
TransactionTable. remoteTransactionCommitted(GlobalTransaction gtx, boolean onePc)
Removes theRemoteTransaction
corresponding to the given tx.void
TransactionTable. remoteTransactionPrepared(GlobalTransaction gtx)
void
TransactionTable. remoteTransactionRollback(GlobalTransaction gtx)
RemoteTransaction
TransactionTable. removeRemoteTransaction(GlobalTransaction txId)
Method parameters in org.infinispan.transaction.impl with type arguments of type GlobalTransaction Modifier and Type Method Description LocalTransaction
TransactionTable. getOrCreateLocalTransaction(Transaction transaction, boolean implicitTransaction, Supplier<GlobalTransaction> gtxFactory)
Similar toTransactionTable.getOrCreateLocalTransaction(Transaction, boolean)
but with a custom global transaction factory.Constructors in org.infinispan.transaction.impl with parameters of type GlobalTransaction Constructor Description AbstractCacheTransaction(GlobalTransaction tx, int topologyId, long txCreationTime)
LocalTransaction(Transaction transaction, GlobalTransaction tx, boolean implicitTransaction, int topologyId, long txCreationTime)
RemoteTransaction(org.infinispan.commands.write.WriteCommand[] modifications, GlobalTransaction tx, int topologyId, long txCreationTime)
RemoteTransaction(GlobalTransaction tx, int topologyId, long txCreationTime)
TotalOrderRemoteTransactionState(GlobalTransaction globalTransaction)
-
Uses of GlobalTransaction in org.infinispan.transaction.synchronization
Constructors in org.infinispan.transaction.synchronization with parameters of type GlobalTransaction Constructor Description SyncLocalTransaction(Transaction transaction, GlobalTransaction tx, boolean implicitTransaction, int topologyId, long txCreationTime)
-
Uses of GlobalTransaction in org.infinispan.transaction.xa
Classes in org.infinispan.transaction.xa with type parameters of type GlobalTransaction Modifier and Type Class Description protected static class
GlobalTransaction.AbstractGlobalTxExternalizer<T extends GlobalTransaction>
Subclasses of GlobalTransaction in org.infinispan.transaction.xa Modifier and Type Class Description class
DldGlobalTransaction
Deprecated.Since 9.0, no longer used.Methods in org.infinispan.transaction.xa that return GlobalTransaction Modifier and Type Method Description protected GlobalTransaction
TransactionFactory.TxFactoryEnum. addCoinToss(DldGlobalTransaction dldGlobalTransaction)
protected GlobalTransaction
GlobalTransaction.Externalizer. createGlobalTransaction()
GlobalTransaction
CacheTransaction. getGlobalTransaction()
Returns the transaction identifier.GlobalTransaction
TransactionFactory. newGlobalTransaction()
GlobalTransaction
TransactionFactory. newGlobalTransaction(Address addr, boolean remote)
abstract GlobalTransaction
TransactionFactory.TxFactoryEnum. newGlobalTransaction()
abstract GlobalTransaction
TransactionFactory.TxFactoryEnum. newGlobalTransaction(Address addr, boolean remote, VersionGenerator clusterIdGenerator, boolean clustered)
Methods in org.infinispan.transaction.xa that return types with arguments of type GlobalTransaction Modifier and Type Method Description Set<Class<? extends GlobalTransaction>>
GlobalTransaction.Externalizer. getTypeClasses()
Methods in org.infinispan.transaction.xa with parameters of type GlobalTransaction Modifier and Type Method Description LocalTransaction
TransactionFactory. newLocalTransaction(Transaction tx, GlobalTransaction gtx, boolean implicitTransaction, int topologyId)
abstract LocalTransaction
TransactionFactory.TxFactoryEnum. newLocalTransaction(Transaction tx, GlobalTransaction gtx, boolean implicitTransaction, int topologyId, long txCreationTime)
RemoteTransaction
TransactionFactory. newRemoteTransaction(org.infinispan.commands.write.WriteCommand[] modifications, GlobalTransaction tx, int topologyId)
RemoteTransaction
TransactionFactory. newRemoteTransaction(GlobalTransaction tx, int topologyId)
abstract RemoteTransaction
TransactionFactory.TxFactoryEnum. newRemoteTransaction(org.infinispan.commands.write.WriteCommand[] modifications, GlobalTransaction tx, int topologyId, long txCreationTime)
abstract RemoteTransaction
TransactionFactory.TxFactoryEnum. newRemoteTransaction(GlobalTransaction tx, int topologyId, long txCreationTime)
Constructors in org.infinispan.transaction.xa with parameters of type GlobalTransaction Constructor Description LocalXaTransaction(Transaction transaction, GlobalTransaction tx, boolean implicitTransaction, int topologyId, long txCreationTime)
-
Uses of GlobalTransaction in org.infinispan.transaction.xa.recovery
Subclasses of GlobalTransaction in org.infinispan.transaction.xa.recovery Modifier and Type Class Description class
RecoveryAwareDldGlobalTransaction
Deprecated.Since 9.0, no longer used.class
RecoveryAwareGlobalTransaction
GlobalTransaction that also holds xid information, required for recovery.Methods in org.infinispan.transaction.xa.recovery with parameters of type GlobalTransaction Modifier and Type Method Description RemoteTransaction
RecoveryAwareTransactionTable. getRemoteTransaction(GlobalTransaction txId)
boolean
RecoveryManager. isTransactionPrepared(GlobalTransaction globalTx)
Checks both internal state and transaction table's state for the given tx.boolean
RecoveryManagerImpl. isTransactionPrepared(GlobalTransaction globalTx)
void
RecoveryAwareTransactionTable. remoteTransactionCommitted(GlobalTransaction gtx, boolean onePc)
void
RecoveryAwareTransactionTable. remoteTransactionPrepared(GlobalTransaction gtx)
Marks the transaction as prepared.void
RecoveryAwareTransactionTable. remoteTransactionRollback(GlobalTransaction gtx)
void
RecoveryManager. removeRecoveryInformation(Collection<Address> where, Xid xid, boolean sync, GlobalTransaction gtx, boolean fromCluster)
Removes from the specified nodes (or all nodes if the value of 'where' is null) the recovery information associated with these Xids.void
RecoveryManagerImpl. removeRecoveryInformation(Collection<Address> lockOwners, Xid xid, boolean sync, GlobalTransaction gtx, boolean fromCluster)
Constructors in org.infinispan.transaction.xa.recovery with parameters of type GlobalTransaction Constructor Description RecoveryAwareLocalTransaction(Transaction transaction, GlobalTransaction tx, boolean implicitTransaction, int topologyId, long txCreationTime)
RecoveryAwareRemoteTransaction(org.infinispan.commands.write.WriteCommand[] modifications, GlobalTransaction tx, int topologyId, long txCreationTime)
RecoveryAwareRemoteTransaction(GlobalTransaction tx, int topologyId, long txCreationTime)
-
Uses of GlobalTransaction in org.infinispan.util.logging
-