| Modifier and Type | Method and Description | 
|---|---|
void | 
LocalTransactionManagerImpl.join(long id,
    TransactionParticipant part,
    long crashCount,
    ServerTransaction xtn)
Deprecated.  
  | 
void | 
LocalTransactionManagerImpl.join(long id,
    TransactionParticipant part,
    long crashCount,
    ServerTransaction userXtnObject,
    int partitionId,
    String clusterName,
    Object clusterProxy)
Deprecated.  
  | 
void | 
LocalTransactionManagerImpl.join(Object id,
    TransactionParticipant part,
    long crashCount,
    ServerTransaction xtn)
Deprecated.  
  | 
void | 
LocalTransactionManagerImpl.join(Object id,
    TransactionParticipant part,
    long crashCount,
    ServerTransaction userXtnObject,
    int partitionId,
    String clusterName,
    Object clusterProxy)
Deprecated.  
  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
GSServerTransaction
Title:       GSServerTransaction Description: Extends the ServerTransaction to hold Object id
 should only be used as a key. 
 | 
| Modifier and Type | Method and Description | 
|---|---|
ServerTransaction | 
GSServerTransaction.createCopy()  | 
protected ServerTransaction | 
GSServerTransaction.createInstance()  | 
| Modifier and Type | Field and Description | 
|---|---|
ServerTransaction | 
LocalCacheContainer.GCEntry._xtn  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
IReplicationNode.outTransaction(IReplicationOutContext context,
              ServerTransaction transaction,
              ArrayList<IEntryHolder> lockedEntries)
Notify replication node that a transaction is executed in one stage (one phase commit) 
 | 
void | 
IReplicationNode.outTransactionAbort(IReplicationOutContext context,
                   ServerTransaction transaction)
Notify replication node that a transaction abort is executed (two phase commit) 
 | 
void | 
IReplicationNode.outTransactionCommit(IReplicationOutContext context,
                    ServerTransaction transaction)
Notify replication node that a transaction commit is executed (two phase commit) 
 | 
void | 
IReplicationNode.outTransactionPrepare(IReplicationOutContext context,
                     ServerTransaction transaction,
                     ArrayList<IEntryHolder> lockedEntries)
Notify replication node that a transaction prepare is executed (two phase commit) 
 | 
| Modifier and Type | Method and Description | 
|---|---|
ServerTransaction | 
ITransactionInContext.getTransaction()  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
ReplicationNode.outTransaction(IReplicationOutContext context,
              ServerTransaction transaction,
              ArrayList<IEntryHolder> lockedEntries)  | 
void | 
ReplicationNode.outTransactionAbort(IReplicationOutContext context,
                   ServerTransaction transaction)  | 
void | 
ReplicationNode.outTransactionCommit(IReplicationOutContext context,
                    ServerTransaction transaction)  | 
void | 
ReplicationNode.outTransactionPrepare(IReplicationOutContext context,
                     ServerTransaction transaction,
                     ArrayList<IEntryHolder> lockedEntries)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
IReplicationAsyncGroupBacklog.addTransaction(IAsyncReplicationGroupOutContext groupContext,
              ServerTransaction transaction,
              ArrayList<IEntryHolder> lockedEntries,
              ReplicationMultipleOperationType operationType)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
MultiBucketSingleFileSyncGroupBacklog.addTransaction(ISyncReplicationGroupOutContext groupContext,
              ServerTransaction transaction,
              ArrayList<IEntryHolder> lockedEntries,
              ReplicationMultipleOperationType operationType)  | 
void | 
MultiBucketSingleFileReliableAsyncGroupBacklog.addTransaction(ReliableAsyncReplicationGroupOutContext groupContext,
              ServerTransaction transaction,
              ArrayList<IEntryHolder> lockedEntries,
              ReplicationMultipleOperationType operationType)  | 
IMultiBucketSingleFileReplicationOrderedPacket | 
AbstractMultiBucketSingleFileGroupBacklog.addTransactionOperationPacket(ISyncReplicationGroupOutContext groupContext,
                             ServerTransaction transaction,
                             ArrayList<IEntryHolder> lockedEntries,
                             ReplicationMultipleOperationType operationType)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
MultiSourceSingleFileAsyncGroupBacklog.addTransaction(IAsyncReplicationGroupOutContext groupContext,
              ServerTransaction transaction,
              ArrayList<IEntryHolder> lockedEntries,
              ReplicationMultipleOperationType operationType)  | 
void | 
MultiSourceSingleFileReliableAsyncGroupBacklog.addTransaction(ReliableAsyncReplicationGroupOutContext groupContext,
              ServerTransaction transaction,
              ArrayList<IEntryHolder> lockedEntries,
              ReplicationMultipleOperationType operationType)  | 
protected IReplicationOrderedPacket | 
AbstractMultiSourceSingleFileGroupBacklog.addTransactionOperationPacket(IReplicationGroupOutContext groupContext,
                             ServerTransaction transaction,
                             ArrayList<IEntryHolder> lockedEntries,
                             ReplicationMultipleOperationType operationType)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
IReplicationReliableAsyncGroupBacklog.addTransaction(ReliableAsyncReplicationGroupOutContext groupContext,
              ServerTransaction transaction,
              ArrayList<IEntryHolder> lockedEntries,
              ReplicationMultipleOperationType operationType)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
IReplicationSyncGroupBacklog.addTransaction(ISyncReplicationGroupOutContext groupContext,
              ServerTransaction transaction,
              ArrayList<IEntryHolder> lockedEntries,
              ReplicationMultipleOperationType operationType)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
IReplicationSourceGroup.beforeTransactionExecute(ReplicationOutContext replicationContext,
                        ServerTransaction transaction,
                        ArrayList<IEntryHolder> lockedEntries,
                        ReplicationMultipleOperationType operationType)
Creates transaction replication data and adds it to the provided context 
 | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
AsyncReplicationSourceGroup.beforeTransactionExecute(ReplicationOutContext replicationContext,
                        ServerTransaction transaction,
                        ArrayList<IEntryHolder> lockedEntries,
                        ReplicationMultipleOperationType operationType)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
ReliableAsyncReplicationSourceGroup.beforeTransactionExecute(ReplicationOutContext replicationContext,
                        ServerTransaction transaction,
                        ArrayList<IEntryHolder> lockedEntries,
                        ReplicationMultipleOperationType operationType)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
SyncReplicationSourceGroup.beforeTransactionExecute(ReplicationOutContext replicationContext,
                        ServerTransaction transaction,
                        ArrayList<IEntryHolder> lockedEntries,
                        ReplicationMultipleOperationType operationType)  | 
| Modifier and Type | Method and Description | 
|---|---|
ServerTransaction | 
AbstractTransactionReplicationPacketData.getTransaction()  | 
ServerTransaction | 
TransactionReplicationPacketData.getTransaction()
Deprecated.  
  | 
| Constructor and Description | 
|---|
AbstractPrepareDependentTransactionReplicationPacketData(ServerTransaction transaction,
                                                        OperationID operationID,
                                                        boolean fromGateway)  | 
AbstractTransactionReplicationPacketData(ServerTransaction transaction,
                                        boolean fromGateway)  | 
TransactionAbortReplicationPacketData(ServerTransaction transaction,
                                     OperationID operationID,
                                     boolean fromGateway)  | 
TransactionCommitReplicationPacketData(ServerTransaction transaction,
                                      OperationID operationID,
                                      boolean fromGateway)  | 
TransactionPrepareReplicationPacketData(ServerTransaction transaction,
                                       boolean fromGateway)  | 
| Modifier and Type | Method and Description | 
|---|---|
ServerTransaction | 
SpaceImpl.createServerTransaction(TransactionManager mgr,
                       Object id,
                       int numOfParticipants)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
SpaceEngine.abort(TransactionManager mgr,
     ServerTransaction st,
     boolean supportsTwoPhaseReplication,
     OperationID operationID)  | 
void | 
SpaceEngine.abortSA(TransactionManager mgr,
       ServerTransaction st,
       boolean fromLeaseExpiration,
       boolean verifyExpiredXtn,
       boolean supportsTwoPhaseReplication,
       OperationID operationID)  | 
XtnEntry | 
SpaceEngine.attachToXtn(ServerTransaction txn,
           boolean fromReplication)
Join the specified transaction, if not already joined. 
 | 
void | 
SpaceEngine.commit(TransactionManager mgr,
      ServerTransaction st,
      boolean supportsTwoPhaseReplication,
      OperationID operationID,
      boolean mayBeFromReplication)  | 
String | 
SpaceEngine.createTransactionDetailsString(ServerTransaction st,
                              OperationID operationID)  | 
XtnEntry | 
SpaceEngine.getTransaction(ServerTransaction st)  | 
protected void | 
SpaceEngine.handleExceptionOnPrepare(TransactionManager mgr,
                        ServerTransaction st,
                        boolean supportsTwoPhaseReplication,
                        XtnEntry xtnEntry)  | 
int | 
SpaceEngine.prepare(TransactionManager mgr,
       ServerTransaction st,
       boolean singleParticipant,
       boolean supportsTwoPhaseReplication,
       OperationID operationID)  | 
int | 
SpaceEngine.prepareAndCommit(TransactionManager mgr,
                ServerTransaction st,
                OperationID operationID)
Prepare and commit the transaction - called for single participant transaction or transaction
 without changes 
 | 
void | 
TemplateScanner.scanNonNotifyTemplates(Context context,
                      IEntryHolder entry,
                      ServerTransaction txn,
                      FifoSearch fifoSearch)
Search for templates that match the specified entry and perform each such template. 
 | 
void | 
TemplateScanner.scanNonNotifyTemplates(Context context,
                      IEntryHolder entry,
                      ServerTransaction txn,
                      FifoSearch fifoSearch,
                      FifoGroupsSearch fifoGroupsSearch)
Search for templates that match the specified entry and perform each such template. 
 | 
void | 
TemplateScanner.scanNotifyTemplates(NotifyContextsHolder notifyContextsHolder,
                   Context context,
                   ServerTransaction txn,
                   FifoSearch fifoSearch)  | 
| Modifier and Type | Method and Description | 
|---|---|
ServerTransaction | 
RecentUpdatesRepository.RecentUpdateInfo.getXtn()  | 
ServerTransaction | 
RecentDeletesRepository.RecentDeleteInfo.getXtn()  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
RecentDeletesRepository.insertToRecentDeletes(IEntryHolder entry,
                     long duration,
                     ServerTransaction xtn)  | 
void | 
RecentUpdatesRepository.insertToRecentUpdates(IEntryHolder entry,
                     long duration,
                     ServerTransaction xtn)  | 
| Constructor and Description | 
|---|
RecentDeleteInfo(String uid,
                long timeBase,
                ServerTransaction xtn)  | 
RecentUpdateInfo(String uid,
                long timeBase,
                ServerTransaction xtn)  | 
| Modifier and Type | Method and Description | 
|---|---|
ServerTransaction | 
EntryHolder.getWriteLockTransaction()  | 
ServerTransaction | 
IEntryHolder.getWriteLockTransaction()  | 
ServerTransaction | 
ITransactionalEntryData.getWriteLockTransaction()  | 
ServerTransaction | 
TemplateHolder.getWriteLockTransaction()  | 
ServerTransaction | 
AbstractEntryData.getWriteLockTransaction()  | 
ServerTransaction | 
EntryHolder.getXidOriginatedTransaction()  | 
ServerTransaction | 
ISpaceItem.getXidOriginatedTransaction()  | 
ServerTransaction | 
ITransactionalEntryData.getXidOriginatedTransaction()  | 
ServerTransaction | 
TemplateHolder.getXidOriginatedTransaction()  | 
ServerTransaction | 
AbstractEntryData.getXidOriginatedTransaction()  | 
| Modifier and Type | Method and Description | 
|---|---|
boolean | 
NotifyTemplateHolder.quickReject(Context context,
           FifoSearch fifoSearch,
           ServerTransaction txn,
           NotifyContextsHolder notifyContextsHolder)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
SynchronizationStorageAdapter.commit(ServerTransaction xtn,
      boolean anyUpdates)  | 
void | 
SynchronizationStorageAdapter.prepare(Context context,
       ServerTransaction xtn,
       ArrayList<IEntryHolder> pLocked,
       boolean singleParticipant,
       Map<String,Object> partialUpdatesAndInPlaceUpdatesInfo,
       boolean shouldReplicate)  | 
void | 
SynchronizationStorageAdapter.rollback(ServerTransaction xtn,
        boolean anyUpdates)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
SyncHybridStorageAdapter.commit(ServerTransaction xtn,
      boolean anyUpdates)  | 
void | 
SyncHybridStorageAdapter.prepare(Context context,
       ServerTransaction xtn,
       ArrayList<IEntryHolder> pLocked,
       boolean singleParticipant,
       Map<String,Object> partialUpdatesAndInPlaceUpdatesInfo,
       boolean shouldReplicate)  | 
void | 
SyncHybridStorageAdapter.rollback(ServerTransaction xtn,
        boolean anyUpdates)  | 
| Modifier and Type | Method and Description | 
|---|---|
ServerTransaction | 
DummyTransactionManager.create()  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
DummyTransactionManager.join(long id,
    TransactionParticipant part,
    long crashCount,
    ServerTransaction userXtnObject)  | 
void | 
DummyTransactionManager.join(long id,
    TransactionParticipant part,
    long crashCount,
    ServerTransaction userXtnObject,
    int partitionId,
    String clusterName,
    Object clusterProxy)  | 
void | 
DummyTransactionManager.join(Object id,
    TransactionParticipant part,
    long crashCount,
    ServerTransaction userXtnObject)  | 
void | 
DummyTransactionManager.join(Object id,
    TransactionParticipant part,
    long crashCount,
    ServerTransaction userXtnObject,
    int partitionId,
    String clusterName,
    Object clusterProxy)  | 
| Modifier and Type | Field and Description | 
|---|---|
ServerTransaction | 
XtnInfo.m_Transaction  | 
ServerTransaction | 
TransactionNotActiveException.m_Xtn  | 
ServerTransaction | 
TransactionConflictException.m_Xtn1  | 
ServerTransaction | 
TransactionConflictException.m_Xtn2  | 
| Modifier and Type | Method and Description | 
|---|---|
ServerTransaction | 
XtnInfo.getServerTransaction()  | 
| Modifier and Type | Method and Description | 
|---|---|
EntryArrivedPacket | 
EntryArrivedPacketsFactory.getPacket(OperationID operationID,
         IEntryHolder entryHolder,
         ServerTransaction xtn,
         boolean notifyListeners,
         IEntryHolder entryValueToNotify,
         boolean fromReplication)
returns a constructed EntryArrivedPacket extracted from the pool of resources. 
 | 
| Constructor and Description | 
|---|
EntryTakenPacket(OperationID operationID,
                IEntryHolder entryHolder,
                ServerTransaction xtn,
                IEntryHolder entryValueToNotify,
                boolean fromReplication)  | 
TransactionConflictException(ServerTransaction Xtn1,
                            ServerTransaction Xtn2)  | 
TransactionNotActiveException(ServerTransaction Xtn)  | 
XtnEntry(ServerTransaction xtn,
        boolean isBackup)
Constructs a new Xtn Entry. 
 | 
XtnInfo(ServerTransaction xtn)
Constructs a new Xtn info. 
 | 
| Modifier and Type | Method and Description | 
|---|---|
ServerTransaction | 
XtnData.getXtn()  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
CacheManager.handleUnderXtnUpdate(Context context,
                    ServerTransaction xtn,
                    IEntryHolder eh,
                    boolean isCommitting,
                    XtnData pXtn)
xtn terminating-handle under xtn updates. 
 | 
void | 
CacheManager.insertToRecentDeletes(IEntryHolder entry,
                     long duration,
                     ServerTransaction committingXtn)  | 
void | 
CacheManager.insertToRecentUpdates(IEntryHolder entry,
                     long duration,
                     ServerTransaction committingXtn)  | 
void | 
CacheManager.insertToRecentUpdatesIfNeeded(IEntryHolder entry,
                             long duration,
                             ServerTransaction committingXtn)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
BlobStoreStorageAdapter.commit(ServerTransaction xtn,
      boolean anyUpdates)  | 
void | 
BlobStoreStorageAdapter.prepare(Context context,
       ServerTransaction xtn,
       ArrayList<IEntryHolder> pLocked,
       boolean singleParticipant,
       Map<String,Object> partialUpdatesAndInPlaceUpdatesInfo,
       boolean shouldReplicate)  | 
void | 
BlobStoreStorageAdapter.rollback(ServerTransaction xtn,
        boolean anyUpdates)  | 
| Modifier and Type | Method and Description | 
|---|---|
ServerTransaction | 
Context.getCommittingXtn()  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
Context.setCommittingXtn(ServerTransaction xtn)  | 
| Modifier and Type | Method and Description | 
|---|---|
ServerTransaction | 
FifoBackgroundRequest.getXtn()  | 
| Constructor and Description | 
|---|
FifoBackgroundRequest(OperationID operID,
                     boolean isNotifyRequest,
                     boolean isNonNotifyRequest,
                     IEntryHolder eh,
                     IEntryHolder originalEntry,
                     boolean fromReplication,
                     int spaceOperation,
                     ServerTransaction txn,
                     IEntryHolder cloneEH)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
MemorySA.commit(ServerTransaction xtn,
      boolean anyUpdates)
Performs commit to transaction- delete taken entries, commit new entries. 
 | 
void | 
IStorageAdapter.commit(ServerTransaction xtn,
      boolean anyUpdates)
Performs commit to transaction- delete taken entries, commit new entries. 
 | 
void | 
MemorySA.prepare(Context context,
       ServerTransaction xtn,
       ArrayList<IEntryHolder> locked_entries,
       boolean singleParticipant,
       Map<String,Object> partialUpdatesAndInPlaceUpdatesInfo,
       boolean shouldReplicate)
Performs prepare to transaction- write to SA all new entries under the xtn, mark taken
 entries under the xtn 
 | 
void | 
IStorageAdapter.prepare(Context context,
       ServerTransaction xtn,
       ArrayList<IEntryHolder> pLocked,
       boolean singleParticipant,
       Map<String,Object> partialUpdatesAndInPlaceUpdatesInfo,
       boolean shouldReplicate)
Performs prepare to transaction- write to SA all new entries under the xtn, mark taken
 entries under the xtn 
 | 
void | 
MemorySA.rollback(ServerTransaction xtn,
        boolean anyUpdates)
Performs rollback to transaction- rewrite taken entries, remove new entries. 
 | 
void | 
IStorageAdapter.rollback(ServerTransaction xtn,
        boolean anyUpdates)
Performs rollback to transaction- rewrite taken entries, remove new entries. 
 | 
| Modifier and Type | Method and Description | 
|---|---|
ServerTransaction | 
BusPacket.getTransaction()  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
BusPacket.constructBusPacket(OperationID operationID,
                  IEntryHolder entryHolder,
                  ServerTransaction xtn,
                  long timeout)
Constructs a BusPacket. 
 | 
void | 
EntryArrivedPacket.constructEntryArrivedPacket(OperationID operationID,
                           IEntryHolder entryHolder,
                           ServerTransaction xtn,
                           boolean notifyListeners,
                           IEntryHolder entryValueToNotify,
                           boolean fromReplication)
Constructs an EntryArrivedPacket 
 | 
void | 
Processor.handleEntryExpiredCoreSA(IEntryHolder entry,
                        ServerTransaction txn,
                        boolean fromReplication)
Handles EntryExpired packets. 
 | 
| Constructor and Description | 
|---|
BusPacket(OperationID operationID,
         IEntryHolder entryHolder,
         ServerTransaction xtn,
         long timeout)
Creates a new BusPacket object. 
 | 
EntryExpiredBusPacket(IEntryHolder entryHolder,
                     ServerTransaction xtn,
                     boolean fromReplication)  | 
EntryUnmatchedPacket(OperationID operationID,
                    IEntryHolder originalEntryHolder,
                    IEntryHolder newEntryHolder,
                    ServerTransaction xtn,
                    boolean fromReplication)
Constructs an EntryArrivedPacket 
 | 
EntryUpdatedPacket(OperationID operationID,
                  IEntryHolder originalEntryHolder,
                  IEntryHolder newEntryHolder,
                  IEntryHolder notifyEH,
                  ServerTransaction xtn,
                  boolean fromReplication,
                  boolean notifyMatch,
                  boolean notifyRematch)
Constructs an EntryUpdatedPacket 
 | 
| Modifier and Type | Method and Description | 
|---|---|
ServerTransaction | 
EntryXtnInfo.getWriteLockTransaction()  | 
ServerTransaction | 
EntryXtnInfo.getXidOriginatedTransaction()  | 
| Modifier and Type | Method and Description | 
|---|---|
ServerTransaction | 
CheckXtnStatusInTmBusPackect.getTx()  | 
| Modifier and Type | Method and Description | 
|---|---|
Map<ServerTransaction,Long> | 
TransactionHandler.getPhantomGlobalXtns()  | 
Map<ServerTransaction,Prepared2PCXtnInfo> | 
TransactionHandler.getPrepared2PCXtns()  | 
Map<ServerTransaction,Long> | 
TransactionHandler.getTimedXtns()  | 
Map<ServerTransaction,XtnEntry> | 
TransactionHandler.getXtnTable()  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
TransactionHandler.addToPhantomGlobalXtns(ServerTransaction xtn)  | 
XtnEntry | 
TransactionHandler.attachToXtnGranular(ServerTransaction txn,
                   boolean fromReplication)
Join the specified transaction, if not already joined. 
 | 
void | 
TransactionHandler.checkTransactionDisconnection(OperationID opid,
                             ServerTransaction txn)  | 
XtnEntry | 
TransactionHandler.createTransactionEntry(ServerTransaction txn)
Create new TransactionEntry and add it to the list of managed transactions 
 | 
XtnEntry | 
TransactionHandler.createTransactionEntryIfAbsent(ServerTransaction txn,
                              XtnEntry newXtnEntry)
Create new TransactionEntry and add it to the list of managed transactions if such xtn does
 not exist. 
 | 
XtnEntry | 
TransactionHandler.getTransactionEntry(ServerTransaction txn)
Get the transaction entry for given transaction. 
 | 
boolean | 
TransactionHandler.isPhantomGlobalXtn(ServerTransaction xtn)  | 
void | 
TransactionHandler.removeFromPhantomGlobalXtns(ServerTransaction xtn)  | 
void | 
TransactionHandler.removeFromPrepared2PCXtns(ServerTransaction xtn)  | 
void | 
TransactionHandler.renewTransactionLease(ServerTransaction txn,
                     long time)  | 
| Constructor and Description | 
|---|
CheckXtnStatusInTmBusPackect(ServerTransaction tx)  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
TxnMgrProxy.join(long id,
    TransactionParticipant part,
    long crashCount,
    ServerTransaction userXtnObject)
Deprecated.  
 | 
void | 
TxnManagerImpl.join(long id,
    TransactionParticipant part,
    long crashCount,
    ServerTransaction userXtnObject)  | 
void | 
TxnMgrProxy.join(long id,
    TransactionParticipant part,
    long crashCount,
    ServerTransaction userXtnObject,
    int partitionId,
    String clusterName,
    Object clusterProxy)  | 
void | 
TxnManagerImpl.join(long id,
    TransactionParticipant part,
    long crashCount,
    ServerTransaction userXtnObject,
    int partitionId,
    String clusterName,
    Object clusterProxy)  | 
void | 
TxnMgrProxy.join(Object id,
    TransactionParticipant part,
    long crashCount,
    ServerTransaction userXtnObject)
Deprecated.  
 | 
void | 
TxnManagerImpl.join(Object xid,
    TransactionParticipant part,
    long crashCount,
    ServerTransaction userXtnObject)  | 
void | 
TxnMgrProxy.join(Object id,
    TransactionParticipant part,
    long crashCount,
    ServerTransaction userXtnObject,
    int partitionId,
    String clusterName,
    Object clusterProxy)  | 
void | 
TxnManagerImpl.join(Object xid,
    TransactionParticipant part,
    long crashCount,
    ServerTransaction userXtnObject,
    int partitionId,
    String clusterName,
    Object clusterProxy)  | 
| Modifier and Type | Class and Description | 
|---|---|
class  | 
NestableServerTransaction
Class implementing the  
NestableTransaction interface, for use with transaction
 participants that implement the default transaction semantics. | 
| Modifier and Type | Method and Description | 
|---|---|
static ServerTransaction | 
ServerTransaction.create(TransactionManager mgr,
      long id,
      long lease)  | 
ServerTransaction | 
ServerTransaction.createCopy()  | 
protected ServerTransaction | 
ServerTransaction.createInstance()
Creates an instance of this class for cloning using the  
createCopy()
 method. | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
ExtendedTransactionManager.join(long id,
    TransactionParticipant part,
    long crashCount,
    ServerTransaction userXtnObject)
Deprecated.  
 | 
void | 
ExtendedTransactionManager.join(long id,
    TransactionParticipant part,
    long crashCount,
    ServerTransaction userXtnObject,
    int partitionId,
    String clusterName,
    Object clusterProxy)  | 
void | 
ExtendedTransactionManager.join(Object id,
    TransactionParticipant part,
    long crashCount,
    ServerTransaction userXtnObject)
Deprecated.  
 | 
void | 
ExtendedTransactionManager.join(Object id,
    TransactionParticipant part,
    long crashCount,
    ServerTransaction userXtnObject,
    int partitionId,
    String clusterName,
    Object clusterProxy)  | 
Copyright © GigaSpaces.