PostgreSQL Source Code  git master
twophase.h File Reference
#include "access/xact.h"
#include "access/xlogdefs.h"
#include "datatype/timestamp.h"
#include "storage/lock.h"
Include dependency graph for twophase.h:
This graph shows which files directly or indirectly include this file:

Go to the source code of this file.

Typedefs

typedef struct GlobalTransactionDataGlobalTransaction
 

Functions

Size TwoPhaseShmemSize (void)
 
void TwoPhaseShmemInit (void)
 
void AtAbort_Twophase (void)
 
void PostPrepare_Twophase (void)
 
TransactionId TwoPhaseGetXidByVirtualXID (VirtualTransactionId vxid, bool *have_more)
 
PGPROCTwoPhaseGetDummyProc (TransactionId xid, bool lock_held)
 
int TwoPhaseGetDummyProcNumber (TransactionId xid, bool lock_held)
 
GlobalTransaction MarkAsPreparing (TransactionId xid, const char *gid, TimestampTz prepared_at, Oid owner, Oid databaseid)
 
void StartPrepare (GlobalTransaction gxact)
 
void EndPrepare (GlobalTransaction gxact)
 
bool StandbyTransactionIdIsPrepared (TransactionId xid)
 
TransactionId PrescanPreparedTransactions (TransactionId **xids_p, int *nxids_p)
 
void StandbyRecoverPreparedTransactions (void)
 
void RecoverPreparedTransactions (void)
 
void CheckPointTwoPhase (XLogRecPtr redo_horizon)
 
void FinishPreparedTransaction (const char *gid, bool isCommit)
 
void PrepareRedoAdd (char *buf, XLogRecPtr start_lsn, XLogRecPtr end_lsn, RepOriginId origin_id)
 
void PrepareRedoRemove (TransactionId xid, bool giveWarning)
 
void restoreTwoPhaseData (void)
 
bool LookupGXact (const char *gid, XLogRecPtr prepare_end_lsn, TimestampTz origin_prepare_timestamp)
 
void TwoPhaseTransactionGid (Oid subid, TransactionId xid, char *gid_res, int szgid)
 
bool LookupGXactBySubid (Oid subid)
 

Variables

PGDLLIMPORT int max_prepared_xacts
 

Typedef Documentation

◆ GlobalTransaction

Definition at line 26 of file twophase.h.

Function Documentation

◆ AtAbort_Twophase()

void AtAbort_Twophase ( void  )

Definition at line 304 of file twophase.c.

305 {
306  if (MyLockedGxact == NULL)
307  return;
308 
309  /*
310  * What to do with the locked global transaction entry? If we were in the
311  * process of preparing the transaction, but haven't written the WAL
312  * record and state file yet, the transaction must not be considered as
313  * prepared. Likewise, if we are in the process of finishing an
314  * already-prepared transaction, and fail after having already written the
315  * 2nd phase commit or rollback record to the WAL, the transaction should
316  * not be considered as prepared anymore. In those cases, just remove the
317  * entry from shared memory.
318  *
319  * Otherwise, the entry must be left in place so that the transaction can
320  * be finished later, so just unlock it.
321  *
322  * If we abort during prepare, after having written the WAL record, we
323  * might not have transferred all locks and other state to the prepared
324  * transaction yet. Likewise, if we abort during commit or rollback,
325  * after having written the WAL record, we might not have released all the
326  * resources held by the transaction yet. In those cases, the in-memory
327  * state can be wrong, but it's too late to back out.
328  */
329  LWLockAcquire(TwoPhaseStateLock, LW_EXCLUSIVE);
330  if (!MyLockedGxact->valid)
332  else
334  LWLockRelease(TwoPhaseStateLock);
335 
336  MyLockedGxact = NULL;
337 }
bool LWLockAcquire(LWLock *lock, LWLockMode mode)
Definition: lwlock.c:1168
void LWLockRelease(LWLock *lock)
Definition: lwlock.c:1781
@ LW_EXCLUSIVE
Definition: lwlock.h:114
#define INVALID_PROC_NUMBER
Definition: procnumber.h:26
ProcNumber locking_backend
Definition: twophase.c:165
static void RemoveGXact(GlobalTransaction gxact)
Definition: twophase.c:628
static GlobalTransaction MyLockedGxact
Definition: twophase.c:196

References INVALID_PROC_NUMBER, GlobalTransactionData::locking_backend, LW_EXCLUSIVE, LWLockAcquire(), LWLockRelease(), MyLockedGxact, RemoveGXact(), and GlobalTransactionData::valid.

Referenced by AbortTransaction(), and AtProcExit_Twophase().

◆ CheckPointTwoPhase()

void CheckPointTwoPhase ( XLogRecPtr  redo_horizon)

Definition at line 1823 of file twophase.c.

1824 {
1825  int i;
1826  int serialized_xacts = 0;
1827 
1828  if (max_prepared_xacts <= 0)
1829  return; /* nothing to do */
1830 
1831  TRACE_POSTGRESQL_TWOPHASE_CHECKPOINT_START();
1832 
1833  /*
1834  * We are expecting there to be zero GXACTs that need to be copied to
1835  * disk, so we perform all I/O while holding TwoPhaseStateLock for
1836  * simplicity. This prevents any new xacts from preparing while this
1837  * occurs, which shouldn't be a problem since the presence of long-lived
1838  * prepared xacts indicates the transaction manager isn't active.
1839  *
1840  * It's also possible to move I/O out of the lock, but on every error we
1841  * should check whether somebody committed our transaction in different
1842  * backend. Let's leave this optimization for future, if somebody will
1843  * spot that this place cause bottleneck.
1844  *
1845  * Note that it isn't possible for there to be a GXACT with a
1846  * prepare_end_lsn set prior to the last checkpoint yet is marked invalid,
1847  * because of the efforts with delayChkptFlags.
1848  */
1849  LWLockAcquire(TwoPhaseStateLock, LW_SHARED);
1850  for (i = 0; i < TwoPhaseState->numPrepXacts; i++)
1851  {
1852  /*
1853  * Note that we are using gxact not PGPROC so this works in recovery
1854  * also
1855  */
1857 
1858  if ((gxact->valid || gxact->inredo) &&
1859  !gxact->ondisk &&
1860  gxact->prepare_end_lsn <= redo_horizon)
1861  {
1862  char *buf;
1863  int len;
1864 
1866  RecreateTwoPhaseFile(gxact->xid, buf, len);
1867  gxact->ondisk = true;
1870  pfree(buf);
1871  serialized_xacts++;
1872  }
1873  }
1874  LWLockRelease(TwoPhaseStateLock);
1875 
1876  /*
1877  * Flush unconditionally the parent directory to make any information
1878  * durable on disk. Two-phase files could have been removed and those
1879  * removals need to be made persistent as well as any files newly created
1880  * previously since the last checkpoint.
1881  */
1882  fsync_fname(TWOPHASE_DIR, true);
1883 
1884  TRACE_POSTGRESQL_TWOPHASE_CHECKPOINT_DONE();
1885 
1886  if (log_checkpoints && serialized_xacts > 0)
1887  ereport(LOG,
1888  (errmsg_plural("%u two-phase state file was written "
1889  "for a long-running prepared transaction",
1890  "%u two-phase state files were written "
1891  "for long-running prepared transactions",
1892  serialized_xacts,
1893  serialized_xacts)));
1894 }
int errmsg_plural(const char *fmt_singular, const char *fmt_plural, unsigned long n,...)
Definition: elog.c:1180
#define LOG
Definition: elog.h:31
#define ereport(elevel,...)
Definition: elog.h:149
void fsync_fname(const char *fname, bool isdir)
Definition: fd.c:756
int i
Definition: isn.c:73
@ LW_SHARED
Definition: lwlock.h:115
void pfree(void *pointer)
Definition: mcxt.c:1521
const void size_t len
static char * buf
Definition: pg_test_fsync.c:73
TransactionId xid
Definition: twophase.c:162
XLogRecPtr prepare_start_lsn
Definition: twophase.c:160
XLogRecPtr prepare_end_lsn
Definition: twophase.c:161
GlobalTransaction prepXacts[FLEXIBLE_ARRAY_MEMBER]
Definition: twophase.c:185
static void XlogReadTwoPhaseData(XLogRecPtr lsn, char **buf, int *len)
Definition: twophase.c:1420
#define TWOPHASE_DIR
Definition: twophase.c:112
int max_prepared_xacts
Definition: twophase.c:115
static TwoPhaseStateData * TwoPhaseState
Definition: twophase.c:188
static void RecreateTwoPhaseFile(TransactionId xid, void *content, int len)
Definition: twophase.c:1743
bool log_checkpoints
Definition: xlog.c:128
#define InvalidXLogRecPtr
Definition: xlogdefs.h:28

References buf, ereport, errmsg_plural(), fsync_fname(), i, GlobalTransactionData::inredo, InvalidXLogRecPtr, len, LOG, log_checkpoints, LW_SHARED, LWLockAcquire(), LWLockRelease(), max_prepared_xacts, TwoPhaseStateData::numPrepXacts, GlobalTransactionData::ondisk, pfree(), GlobalTransactionData::prepare_end_lsn, GlobalTransactionData::prepare_start_lsn, TwoPhaseStateData::prepXacts, RecreateTwoPhaseFile(), TWOPHASE_DIR, TwoPhaseState, GlobalTransactionData::valid, GlobalTransactionData::xid, and XlogReadTwoPhaseData().

Referenced by CheckPointGuts().

◆ EndPrepare()

void EndPrepare ( GlobalTransaction  gxact)

Definition at line 1158 of file twophase.c.

1159 {
1160  TwoPhaseFileHeader *hdr;
1161  StateFileChunk *record;
1162  bool replorigin;
1163 
1164  /* Add the end sentinel to the list of 2PC records */
1166  NULL, 0);
1167 
1168  /* Go back and fill in total_len in the file header record */
1169  hdr = (TwoPhaseFileHeader *) records.head->data;
1170  Assert(hdr->magic == TWOPHASE_MAGIC);
1171  hdr->total_len = records.total_len + sizeof(pg_crc32c);
1172 
1173  replorigin = (replorigin_session_origin != InvalidRepOriginId &&
1175 
1176  if (replorigin)
1177  {
1180  }
1181 
1182  /*
1183  * If the data size exceeds MaxAllocSize, we won't be able to read it in
1184  * ReadTwoPhaseFile. Check for that now, rather than fail in the case
1185  * where we write data to file and then re-read at commit time.
1186  */
1187  if (hdr->total_len > MaxAllocSize)
1188  ereport(ERROR,
1189  (errcode(ERRCODE_PROGRAM_LIMIT_EXCEEDED),
1190  errmsg("two-phase state file maximum length exceeded")));
1191 
1192  /*
1193  * Now writing 2PC state data to WAL. We let the WAL's CRC protection
1194  * cover us, so no need to calculate a separate CRC.
1195  *
1196  * We have to set DELAY_CHKPT_START here, too; otherwise a checkpoint
1197  * starting immediately after the WAL record is inserted could complete
1198  * without fsync'ing our state file. (This is essentially the same kind
1199  * of race condition as the COMMIT-to-clog-write case that
1200  * RecordTransactionCommit uses DELAY_CHKPT_START for; see notes there.)
1201  *
1202  * We save the PREPARE record's location in the gxact for later use by
1203  * CheckPointTwoPhase.
1204  */
1206 
1208 
1211 
1212  XLogBeginInsert();
1213  for (record = records.head; record != NULL; record = record->next)
1214  XLogRegisterData(record->data, record->len);
1215 
1217 
1218  gxact->prepare_end_lsn = XLogInsert(RM_XACT_ID, XLOG_XACT_PREPARE);
1219 
1220  if (replorigin)
1221  {
1222  /* Move LSNs forward for this replication origin */
1224  gxact->prepare_end_lsn);
1225  }
1226 
1227  XLogFlush(gxact->prepare_end_lsn);
1228 
1229  /* If we crash now, we have prepared: WAL replay will fix things */
1230 
1231  /* Store record's start location to read that later on Commit */
1233 
1234  /*
1235  * Mark the prepared transaction as valid. As soon as xact.c marks MyProc
1236  * as not running our XID (which it will do immediately after this
1237  * function returns), others can commit/rollback the xact.
1238  *
1239  * NB: a side effect of this is to make a dummy ProcArray entry for the
1240  * prepared XID. This must happen before we clear the XID from MyProc /
1241  * ProcGlobal->xids[], else there is a window where the XID is not running
1242  * according to TransactionIdIsInProgress, and onlookers would be entitled
1243  * to assume the xact crashed. Instead we have a window where the same
1244  * XID appears twice in ProcArray, which is OK.
1245  */
1246  MarkAsPrepared(gxact, false);
1247 
1248  /*
1249  * Now we can mark ourselves as out of the commit critical section: a
1250  * checkpoint starting after this will certainly see the gxact as a
1251  * candidate for fsyncing.
1252  */
1254 
1255  /*
1256  * Remember that we have this GlobalTransaction entry locked for us. If
1257  * we crash after this point, it's too late to abort, but we must unlock
1258  * it so that the prepared transaction can be committed or rolled back.
1259  */
1260  MyLockedGxact = gxact;
1261 
1262  END_CRIT_SECTION();
1263 
1264  /*
1265  * Wait for synchronous replication, if required.
1266  *
1267  * Note that at this stage we have marked the prepare, but still show as
1268  * running in the procarray (twice!) and continue to hold locks.
1269  */
1270  SyncRepWaitForLSN(gxact->prepare_end_lsn, false);
1271 
1272  records.tail = records.head = NULL;
1273  records.num_chunks = 0;
1274 }
#define Assert(condition)
Definition: c.h:849
int errcode(int sqlerrcode)
Definition: elog.c:853
int errmsg(const char *fmt,...)
Definition: elog.c:1070
#define ERROR
Definition: elog.h:39
#define MaxAllocSize
Definition: memutils.h:40
#define START_CRIT_SECTION()
Definition: miscadmin.h:149
#define END_CRIT_SECTION()
Definition: miscadmin.h:151
TimestampTz replorigin_session_origin_timestamp
Definition: origin.c:161
void replorigin_session_advance(XLogRecPtr remote_commit, XLogRecPtr local_commit)
Definition: origin.c:1223
RepOriginId replorigin_session_origin
Definition: origin.c:159
XLogRecPtr replorigin_session_origin_lsn
Definition: origin.c:160
#define DoNotReplicateId
Definition: origin.h:34
#define InvalidRepOriginId
Definition: origin.h:33
uint32 pg_crc32c
Definition: pg_crc32c.h:38
#define DELAY_CHKPT_START
Definition: proc.h:119
PGPROC * MyProc
Definition: proc.c:67
int delayChkptFlags
Definition: proc.h:240
struct StateFileChunk * next
Definition: twophase.c:1015
TimestampTz origin_timestamp
Definition: xact.h:369
uint32 total_len
Definition: xact.h:355
XLogRecPtr origin_lsn
Definition: xact.h:368
uint32 magic
Definition: xact.h:354
uint32 total_len
Definition: twophase.c:1024
uint32 num_chunks
Definition: twophase.c:1022
StateFileChunk * head
Definition: twophase.c:1020
StateFileChunk * tail
Definition: twophase.c:1021
void SyncRepWaitForLSN(XLogRecPtr lsn, bool commit)
Definition: syncrep.c:148
void RegisterTwoPhaseRecord(TwoPhaseRmgrId rmid, uint16 info, const void *data, uint32 len)
Definition: twophase.c:1280
#define TWOPHASE_MAGIC
Definition: twophase.c:989
static void MarkAsPrepared(GlobalTransaction gxact, bool lock_held)
Definition: twophase.c:530
static struct xllist records
#define TWOPHASE_RM_END_ID
Definition: twophase_rmgr.h:24
#define XLOG_XACT_PREPARE
Definition: xact.h:170
XLogRecPtr ProcLastRecPtr
Definition: xlog.c:252
void XLogFlush(XLogRecPtr record)
Definition: xlog.c:2795
#define XLOG_INCLUDE_ORIGIN
Definition: xlog.h:154
XLogRecPtr XLogInsert(RmgrId rmid, uint8 info)
Definition: xloginsert.c:474
void XLogSetRecordFlags(uint8 flags)
Definition: xloginsert.c:456
void XLogRegisterData(const char *data, uint32 len)
Definition: xloginsert.c:364
void XLogBeginInsert(void)
Definition: xloginsert.c:149
void XLogEnsureRecordSpace(int max_block_id, int ndatas)
Definition: xloginsert.c:175

References Assert, StateFileChunk::data, DELAY_CHKPT_START, PGPROC::delayChkptFlags, DoNotReplicateId, END_CRIT_SECTION, ereport, errcode(), errmsg(), ERROR, xllist::head, InvalidRepOriginId, StateFileChunk::len, xl_xact_prepare::magic, MarkAsPrepared(), MaxAllocSize, MyLockedGxact, MyProc, StateFileChunk::next, xllist::num_chunks, xl_xact_prepare::origin_lsn, xl_xact_prepare::origin_timestamp, GlobalTransactionData::prepare_end_lsn, GlobalTransactionData::prepare_start_lsn, ProcLastRecPtr, records, RegisterTwoPhaseRecord(), replorigin_session_advance(), replorigin_session_origin, replorigin_session_origin_lsn, replorigin_session_origin_timestamp, START_CRIT_SECTION, SyncRepWaitForLSN(), xllist::tail, xllist::total_len, xl_xact_prepare::total_len, TWOPHASE_MAGIC, TWOPHASE_RM_END_ID, XLOG_INCLUDE_ORIGIN, XLOG_XACT_PREPARE, XLogBeginInsert(), XLogEnsureRecordSpace(), XLogFlush(), XLogInsert(), XLogRegisterData(), and XLogSetRecordFlags().

Referenced by PrepareTransaction().

◆ FinishPreparedTransaction()

void FinishPreparedTransaction ( const char *  gid,
bool  isCommit 
)

Definition at line 1503 of file twophase.c.

1504 {
1505  GlobalTransaction gxact;
1506  PGPROC *proc;
1507  TransactionId xid;
1508  bool ondisk;
1509  char *buf;
1510  char *bufptr;
1511  TwoPhaseFileHeader *hdr;
1512  TransactionId latestXid;
1513  TransactionId *children;
1514  RelFileLocator *commitrels;
1515  RelFileLocator *abortrels;
1516  RelFileLocator *delrels;
1517  int ndelrels;
1518  xl_xact_stats_item *commitstats;
1519  xl_xact_stats_item *abortstats;
1520  SharedInvalidationMessage *invalmsgs;
1521 
1522  /*
1523  * Validate the GID, and lock the GXACT to ensure that two backends do not
1524  * try to commit the same GID at once.
1525  */
1526  gxact = LockGXact(gid, GetUserId());
1527  proc = GetPGProcByNumber(gxact->pgprocno);
1528  xid = gxact->xid;
1529 
1530  /*
1531  * Read and validate 2PC state data. State data will typically be stored
1532  * in WAL files if the LSN is after the last checkpoint record, or moved
1533  * to disk if for some reason they have lived for a long time.
1534  */
1535  if (gxact->ondisk)
1536  buf = ReadTwoPhaseFile(xid, false);
1537  else
1538  XlogReadTwoPhaseData(gxact->prepare_start_lsn, &buf, NULL);
1539 
1540 
1541  /*
1542  * Disassemble the header area
1543  */
1544  hdr = (TwoPhaseFileHeader *) buf;
1545  Assert(TransactionIdEquals(hdr->xid, xid));
1546  bufptr = buf + MAXALIGN(sizeof(TwoPhaseFileHeader));
1547  bufptr += MAXALIGN(hdr->gidlen);
1548  children = (TransactionId *) bufptr;
1549  bufptr += MAXALIGN(hdr->nsubxacts * sizeof(TransactionId));
1550  commitrels = (RelFileLocator *) bufptr;
1551  bufptr += MAXALIGN(hdr->ncommitrels * sizeof(RelFileLocator));
1552  abortrels = (RelFileLocator *) bufptr;
1553  bufptr += MAXALIGN(hdr->nabortrels * sizeof(RelFileLocator));
1554  commitstats = (xl_xact_stats_item *) bufptr;
1555  bufptr += MAXALIGN(hdr->ncommitstats * sizeof(xl_xact_stats_item));
1556  abortstats = (xl_xact_stats_item *) bufptr;
1557  bufptr += MAXALIGN(hdr->nabortstats * sizeof(xl_xact_stats_item));
1558  invalmsgs = (SharedInvalidationMessage *) bufptr;
1559  bufptr += MAXALIGN(hdr->ninvalmsgs * sizeof(SharedInvalidationMessage));
1560 
1561  /* compute latestXid among all children */
1562  latestXid = TransactionIdLatest(xid, hdr->nsubxacts, children);
1563 
1564  /* Prevent cancel/die interrupt while cleaning up */
1565  HOLD_INTERRUPTS();
1566 
1567  /*
1568  * The order of operations here is critical: make the XLOG entry for
1569  * commit or abort, then mark the transaction committed or aborted in
1570  * pg_xact, then remove its PGPROC from the global ProcArray (which means
1571  * TransactionIdIsInProgress will stop saying the prepared xact is in
1572  * progress), then run the post-commit or post-abort callbacks. The
1573  * callbacks will release the locks the transaction held.
1574  */
1575  if (isCommit)
1577  hdr->nsubxacts, children,
1578  hdr->ncommitrels, commitrels,
1579  hdr->ncommitstats,
1580  commitstats,
1581  hdr->ninvalmsgs, invalmsgs,
1582  hdr->initfileinval, gid);
1583  else
1585  hdr->nsubxacts, children,
1586  hdr->nabortrels, abortrels,
1587  hdr->nabortstats,
1588  abortstats,
1589  gid);
1590 
1591  ProcArrayRemove(proc, latestXid);
1592 
1593  /*
1594  * In case we fail while running the callbacks, mark the gxact invalid so
1595  * no one else will try to commit/rollback, and so it will be recycled if
1596  * we fail after this point. It is still locked by our backend so it
1597  * won't go away yet.
1598  *
1599  * (We assume it's safe to do this without taking TwoPhaseStateLock.)
1600  */
1601  gxact->valid = false;
1602 
1603  /*
1604  * We have to remove any files that were supposed to be dropped. For
1605  * consistency with the regular xact.c code paths, must do this before
1606  * releasing locks, so do it before running the callbacks.
1607  *
1608  * NB: this code knows that we couldn't be dropping any temp rels ...
1609  */
1610  if (isCommit)
1611  {
1612  delrels = commitrels;
1613  ndelrels = hdr->ncommitrels;
1614  }
1615  else
1616  {
1617  delrels = abortrels;
1618  ndelrels = hdr->nabortrels;
1619  }
1620 
1621  /* Make sure files supposed to be dropped are dropped */
1622  DropRelationFiles(delrels, ndelrels, false);
1623 
1624  if (isCommit)
1625  pgstat_execute_transactional_drops(hdr->ncommitstats, commitstats, false);
1626  else
1627  pgstat_execute_transactional_drops(hdr->nabortstats, abortstats, false);
1628 
1629  /*
1630  * Handle cache invalidation messages.
1631  *
1632  * Relcache init file invalidation requires processing both before and
1633  * after we send the SI messages, only when committing. See
1634  * AtEOXact_Inval().
1635  */
1636  if (isCommit)
1637  {
1638  if (hdr->initfileinval)
1640  SendSharedInvalidMessages(invalmsgs, hdr->ninvalmsgs);
1641  if (hdr->initfileinval)
1643  }
1644 
1645  /*
1646  * Acquire the two-phase lock. We want to work on the two-phase callbacks
1647  * while holding it to avoid potential conflicts with other transactions
1648  * attempting to use the same GID, so the lock is released once the shared
1649  * memory state is cleared.
1650  */
1651  LWLockAcquire(TwoPhaseStateLock, LW_EXCLUSIVE);
1652 
1653  /* And now do the callbacks */
1654  if (isCommit)
1656  else
1658 
1659  PredicateLockTwoPhaseFinish(xid, isCommit);
1660 
1661  /*
1662  * Read this value while holding the two-phase lock, as the on-disk 2PC
1663  * file is physically removed after the lock is released.
1664  */
1665  ondisk = gxact->ondisk;
1666 
1667  /* Clear shared memory state */
1668  RemoveGXact(gxact);
1669 
1670  /*
1671  * Release the lock as all callbacks are called and shared memory cleanup
1672  * is done.
1673  */
1674  LWLockRelease(TwoPhaseStateLock);
1675 
1676  /* Count the prepared xact as committed or aborted */
1677  AtEOXact_PgStat(isCommit, false);
1678 
1679  /*
1680  * And now we can clean up any files we may have left.
1681  */
1682  if (ondisk)
1683  RemoveTwoPhaseFile(xid, true);
1684 
1685  MyLockedGxact = NULL;
1686 
1688 
1689  pfree(buf);
1690 }
#define MAXALIGN(LEN)
Definition: c.h:802
uint32 TransactionId
Definition: c.h:643
void DropRelationFiles(RelFileLocator *delrels, int ndelrels, bool isRedo)
Definition: md.c:1467
#define RESUME_INTERRUPTS()
Definition: miscadmin.h:135
#define HOLD_INTERRUPTS()
Definition: miscadmin.h:133
Oid GetUserId(void)
Definition: miscinit.c:514
void pgstat_execute_transactional_drops(int ndrops, struct xl_xact_stats_item *items, bool is_redo)
Definition: pgstat_xact.c:314
void AtEOXact_PgStat(bool isCommit, bool parallel)
Definition: pgstat_xact.c:40
void PredicateLockTwoPhaseFinish(TransactionId xid, bool isCommit)
Definition: predicate.c:4872
#define GetPGProcByNumber(n)
Definition: proc.h:432
void ProcArrayRemove(PGPROC *proc, TransactionId latestXid)
Definition: procarray.c:565
void RelationCacheInitFilePostInvalidate(void)
Definition: relcache.c:6795
void RelationCacheInitFilePreInvalidate(void)
Definition: relcache.c:6770
void SendSharedInvalidMessages(const SharedInvalidationMessage *msgs, int n)
Definition: sinval.c:47
Definition: proc.h:162
int32 nabortrels
Definition: xact.h:362
int32 ninvalmsgs
Definition: xact.h:365
bool initfileinval
Definition: xact.h:366
int32 ncommitstats
Definition: xact.h:363
uint16 gidlen
Definition: xact.h:367
int32 nabortstats
Definition: xact.h:364
int32 ncommitrels
Definition: xact.h:361
TransactionId xid
Definition: xact.h:356
int32 nsubxacts
Definition: xact.h:360
TransactionId TransactionIdLatest(TransactionId mainxid, int nxids, const TransactionId *xids)
Definition: transam.c:345
#define TransactionIdEquals(id1, id2)
Definition: transam.h:43
static void RecordTransactionAbortPrepared(TransactionId xid, int nchildren, TransactionId *children, int nrels, RelFileLocator *rels, int nstats, xl_xact_stats_item *stats, const char *gid)
Definition: twophase.c:2411
static void RecordTransactionCommitPrepared(TransactionId xid, int nchildren, TransactionId *children, int nrels, RelFileLocator *rels, int nstats, xl_xact_stats_item *stats, int ninvalmsgs, SharedInvalidationMessage *invalmsgs, bool initfileinval, const char *gid)
Definition: twophase.c:2313
static void ProcessRecords(char *bufptr, TransactionId xid, const TwoPhaseCallback callbacks[])
Definition: twophase.c:1696
static void RemoveTwoPhaseFile(TransactionId xid, bool giveWarning)
Definition: twophase.c:1724
static char * ReadTwoPhaseFile(TransactionId xid, bool missing_ok)
Definition: twophase.c:1303
static GlobalTransaction LockGXact(const char *gid, Oid user)
Definition: twophase.c:552
const TwoPhaseCallback twophase_postcommit_callbacks[TWOPHASE_RM_MAX_ID+1]
Definition: twophase_rmgr.c:33
const TwoPhaseCallback twophase_postabort_callbacks[TWOPHASE_RM_MAX_ID+1]
Definition: twophase_rmgr.c:42

References Assert, AtEOXact_PgStat(), buf, DropRelationFiles(), GetPGProcByNumber, GetUserId(), xl_xact_prepare::gidlen, HOLD_INTERRUPTS, xl_xact_prepare::initfileinval, LockGXact(), LW_EXCLUSIVE, LWLockAcquire(), LWLockRelease(), MAXALIGN, MyLockedGxact, xl_xact_prepare::nabortrels, xl_xact_prepare::nabortstats, xl_xact_prepare::ncommitrels, xl_xact_prepare::ncommitstats, xl_xact_prepare::ninvalmsgs, xl_xact_prepare::nsubxacts, GlobalTransactionData::ondisk, pfree(), GlobalTransactionData::pgprocno, pgstat_execute_transactional_drops(), PredicateLockTwoPhaseFinish(), GlobalTransactionData::prepare_start_lsn, ProcArrayRemove(), ProcessRecords(), ReadTwoPhaseFile(), RecordTransactionAbortPrepared(), RecordTransactionCommitPrepared(), RelationCacheInitFilePostInvalidate(), RelationCacheInitFilePreInvalidate(), RemoveGXact(), RemoveTwoPhaseFile(), RESUME_INTERRUPTS, SendSharedInvalidMessages(), TransactionIdEquals, TransactionIdLatest(), twophase_postabort_callbacks, twophase_postcommit_callbacks, GlobalTransactionData::valid, GlobalTransactionData::xid, xl_xact_prepare::xid, and XlogReadTwoPhaseData().

Referenced by apply_handle_commit_prepared(), apply_handle_rollback_prepared(), and standard_ProcessUtility().

◆ LookupGXact()

bool LookupGXact ( const char *  gid,
XLogRecPtr  prepare_end_lsn,
TimestampTz  origin_prepare_timestamp 
)

Definition at line 2640 of file twophase.c.

2642 {
2643  int i;
2644  bool found = false;
2645 
2646  LWLockAcquire(TwoPhaseStateLock, LW_SHARED);
2647  for (i = 0; i < TwoPhaseState->numPrepXacts; i++)
2648  {
2650 
2651  /* Ignore not-yet-valid GIDs. */
2652  if (gxact->valid && strcmp(gxact->gid, gid) == 0)
2653  {
2654  char *buf;
2655  TwoPhaseFileHeader *hdr;
2656 
2657  /*
2658  * We are not expecting collisions of GXACTs (same gid) between
2659  * publisher and subscribers, so we perform all I/O while holding
2660  * TwoPhaseStateLock for simplicity.
2661  *
2662  * To move the I/O out of the lock, we need to ensure that no
2663  * other backend commits the prepared xact in the meantime. We can
2664  * do this optimization if we encounter many collisions in GID
2665  * between publisher and subscriber.
2666  */
2667  if (gxact->ondisk)
2668  buf = ReadTwoPhaseFile(gxact->xid, false);
2669  else
2670  {
2671  Assert(gxact->prepare_start_lsn);
2672  XlogReadTwoPhaseData(gxact->prepare_start_lsn, &buf, NULL);
2673  }
2674 
2675  hdr = (TwoPhaseFileHeader *) buf;
2676 
2677  if (hdr->origin_lsn == prepare_end_lsn &&
2678  hdr->origin_timestamp == origin_prepare_timestamp)
2679  {
2680  found = true;
2681  pfree(buf);
2682  break;
2683  }
2684 
2685  pfree(buf);
2686  }
2687  }
2688  LWLockRelease(TwoPhaseStateLock);
2689  return found;
2690 }
char gid[GIDSIZE]
Definition: twophase.c:169

References Assert, buf, GlobalTransactionData::gid, i, LW_SHARED, LWLockAcquire(), LWLockRelease(), TwoPhaseStateData::numPrepXacts, GlobalTransactionData::ondisk, xl_xact_prepare::origin_lsn, xl_xact_prepare::origin_timestamp, pfree(), GlobalTransactionData::prepare_start_lsn, TwoPhaseStateData::prepXacts, ReadTwoPhaseFile(), TwoPhaseState, GlobalTransactionData::valid, GlobalTransactionData::xid, and XlogReadTwoPhaseData().

Referenced by apply_handle_rollback_prepared().

◆ LookupGXactBySubid()

bool LookupGXactBySubid ( Oid  subid)

Definition at line 2749 of file twophase.c.

2750 {
2751  bool found = false;
2752 
2753  LWLockAcquire(TwoPhaseStateLock, LW_SHARED);
2754  for (int i = 0; i < TwoPhaseState->numPrepXacts; i++)
2755  {
2757 
2758  /* Ignore not-yet-valid GIDs. */
2759  if (gxact->valid &&
2760  IsTwoPhaseTransactionGidForSubid(subid, gxact->gid))
2761  {
2762  found = true;
2763  break;
2764  }
2765  }
2766  LWLockRelease(TwoPhaseStateLock);
2767 
2768  return found;
2769 }
static bool IsTwoPhaseTransactionGidForSubid(Oid subid, char *gid)
Definition: twophase.c:2717

References GlobalTransactionData::gid, i, IsTwoPhaseTransactionGidForSubid(), LW_SHARED, LWLockAcquire(), LWLockRelease(), TwoPhaseStateData::numPrepXacts, TwoPhaseStateData::prepXacts, TwoPhaseState, and GlobalTransactionData::valid.

Referenced by AlterSubscription().

◆ MarkAsPreparing()

GlobalTransaction MarkAsPreparing ( TransactionId  xid,
const char *  gid,
TimestampTz  prepared_at,
Oid  owner,
Oid  databaseid 
)

Definition at line 359 of file twophase.c.

361 {
362  GlobalTransaction gxact;
363  int i;
364 
365  if (strlen(gid) >= GIDSIZE)
366  ereport(ERROR,
367  (errcode(ERRCODE_INVALID_PARAMETER_VALUE),
368  errmsg("transaction identifier \"%s\" is too long",
369  gid)));
370 
371  /* fail immediately if feature is disabled */
372  if (max_prepared_xacts == 0)
373  ereport(ERROR,
374  (errcode(ERRCODE_OBJECT_NOT_IN_PREREQUISITE_STATE),
375  errmsg("prepared transactions are disabled"),
376  errhint("Set \"max_prepared_transactions\" to a nonzero value.")));
377 
378  /* on first call, register the exit hook */
380  {
382  twophaseExitRegistered = true;
383  }
384 
385  LWLockAcquire(TwoPhaseStateLock, LW_EXCLUSIVE);
386 
387  /* Check for conflicting GID */
388  for (i = 0; i < TwoPhaseState->numPrepXacts; i++)
389  {
390  gxact = TwoPhaseState->prepXacts[i];
391  if (strcmp(gxact->gid, gid) == 0)
392  {
393  ereport(ERROR,
395  errmsg("transaction identifier \"%s\" is already in use",
396  gid)));
397  }
398  }
399 
400  /* Get a free gxact from the freelist */
401  if (TwoPhaseState->freeGXacts == NULL)
402  ereport(ERROR,
403  (errcode(ERRCODE_OUT_OF_MEMORY),
404  errmsg("maximum number of prepared transactions reached"),
405  errhint("Increase \"max_prepared_transactions\" (currently %d).",
407  gxact = TwoPhaseState->freeGXacts;
408  TwoPhaseState->freeGXacts = gxact->next;
409 
410  MarkAsPreparingGuts(gxact, xid, gid, prepared_at, owner, databaseid);
411 
412  gxact->ondisk = false;
413 
414  /* And insert it into the active array */
417 
418  LWLockRelease(TwoPhaseStateLock);
419 
420  return gxact;
421 }
int errhint(const char *fmt,...)
Definition: elog.c:1317
void before_shmem_exit(pg_on_exit_callback function, Datum arg)
Definition: ipc.c:337
#define ERRCODE_DUPLICATE_OBJECT
Definition: streamutil.c:32
GlobalTransaction next
Definition: twophase.c:149
GlobalTransaction freeGXacts
Definition: twophase.c:179
static bool twophaseExitRegistered
Definition: twophase.c:198
static void MarkAsPreparingGuts(GlobalTransaction gxact, TransactionId xid, const char *gid, TimestampTz prepared_at, Oid owner, Oid databaseid)
Definition: twophase.c:433
static void AtProcExit_Twophase(int code, Datum arg)
Definition: twophase.c:294
#define GIDSIZE
Definition: xact.h:31

References Assert, AtProcExit_Twophase(), before_shmem_exit(), ereport, errcode(), ERRCODE_DUPLICATE_OBJECT, errhint(), errmsg(), ERROR, TwoPhaseStateData::freeGXacts, GlobalTransactionData::gid, GIDSIZE, i, LW_EXCLUSIVE, LWLockAcquire(), LWLockRelease(), MarkAsPreparingGuts(), max_prepared_xacts, GlobalTransactionData::next, TwoPhaseStateData::numPrepXacts, GlobalTransactionData::ondisk, TwoPhaseStateData::prepXacts, twophaseExitRegistered, and TwoPhaseState.

Referenced by PrepareTransaction().

◆ PostPrepare_Twophase()

void PostPrepare_Twophase ( void  )

Definition at line 344 of file twophase.c.

345 {
346  LWLockAcquire(TwoPhaseStateLock, LW_EXCLUSIVE);
348  LWLockRelease(TwoPhaseStateLock);
349 
350  MyLockedGxact = NULL;
351 }

References INVALID_PROC_NUMBER, GlobalTransactionData::locking_backend, LW_EXCLUSIVE, LWLockAcquire(), LWLockRelease(), and MyLockedGxact.

Referenced by PrepareTransaction(), and RecoverPreparedTransactions().

◆ PrepareRedoAdd()

void PrepareRedoAdd ( char *  buf,
XLogRecPtr  start_lsn,
XLogRecPtr  end_lsn,
RepOriginId  origin_id 
)

Definition at line 2486 of file twophase.c.

2488 {
2490  char *bufptr;
2491  const char *gid;
2492  GlobalTransaction gxact;
2493 
2494  Assert(LWLockHeldByMeInMode(TwoPhaseStateLock, LW_EXCLUSIVE));
2496 
2497  bufptr = buf + MAXALIGN(sizeof(TwoPhaseFileHeader));
2498  gid = (const char *) bufptr;
2499 
2500  /*
2501  * Reserve the GID for the given transaction in the redo code path.
2502  *
2503  * This creates a gxact struct and puts it into the active array.
2504  *
2505  * In redo, this struct is mainly used to track PREPARE/COMMIT entries in
2506  * shared memory. Hence, we only fill up the bare minimum contents here.
2507  * The gxact also gets marked with gxact->inredo set to true to indicate
2508  * that it got added in the redo phase
2509  */
2510 
2511  /*
2512  * In the event of a crash while a checkpoint was running, it may be
2513  * possible that some two-phase data found its way to disk while its
2514  * corresponding record needs to be replayed in the follow-up recovery. As
2515  * the 2PC data was on disk, it has already been restored at the beginning
2516  * of recovery with restoreTwoPhaseData(), so skip this record to avoid
2517  * duplicates in TwoPhaseState. If a consistent state has been reached,
2518  * the record is added to TwoPhaseState and it should have no
2519  * corresponding file in pg_twophase.
2520  */
2521  if (!XLogRecPtrIsInvalid(start_lsn))
2522  {
2523  char path[MAXPGPATH];
2524 
2525  TwoPhaseFilePath(path, hdr->xid);
2526 
2527  if (access(path, F_OK) == 0)
2528  {
2530  (errmsg("could not recover two-phase state file for transaction %u",
2531  hdr->xid),
2532  errdetail("Two-phase state file has been found in WAL record %X/%X, but this transaction has already been restored from disk.",
2533  LSN_FORMAT_ARGS(start_lsn))));
2534  return;
2535  }
2536 
2537  if (errno != ENOENT)
2538  ereport(ERROR,
2540  errmsg("could not access file \"%s\": %m", path)));
2541  }
2542 
2543  /* Get a free gxact from the freelist */
2544  if (TwoPhaseState->freeGXacts == NULL)
2545  ereport(ERROR,
2546  (errcode(ERRCODE_OUT_OF_MEMORY),
2547  errmsg("maximum number of prepared transactions reached"),
2548  errhint("Increase \"max_prepared_transactions\" (currently %d).",
2549  max_prepared_xacts)));
2550  gxact = TwoPhaseState->freeGXacts;
2551  TwoPhaseState->freeGXacts = gxact->next;
2552 
2553  gxact->prepared_at = hdr->prepared_at;
2554  gxact->prepare_start_lsn = start_lsn;
2555  gxact->prepare_end_lsn = end_lsn;
2556  gxact->xid = hdr->xid;
2557  gxact->owner = hdr->owner;
2559  gxact->valid = false;
2560  gxact->ondisk = XLogRecPtrIsInvalid(start_lsn);
2561  gxact->inredo = true; /* yes, added in redo */
2562  strcpy(gxact->gid, gid);
2563 
2564  /* And insert it into the active array */
2567 
2568  if (origin_id != InvalidRepOriginId)
2569  {
2570  /* recover apply progress */
2571  replorigin_advance(origin_id, hdr->origin_lsn, end_lsn,
2572  false /* backward */ , false /* WAL */ );
2573  }
2574 
2575  elog(DEBUG2, "added 2PC data in shared memory for transaction %u", gxact->xid);
2576 }
int errcode_for_file_access(void)
Definition: elog.c:876
int errdetail(const char *fmt,...)
Definition: elog.c:1203
#define WARNING
Definition: elog.h:36
#define DEBUG2
Definition: elog.h:29
#define elog(elevel,...)
Definition: elog.h:225
bool LWLockHeldByMeInMode(LWLock *lock, LWLockMode mode)
Definition: lwlock.c:1937
void replorigin_advance(RepOriginId node, XLogRecPtr remote_commit, XLogRecPtr local_commit, bool go_backward, bool wal_log)
Definition: origin.c:892
#define MAXPGPATH
short access
Definition: preproc-type.c:36
TimestampTz prepared_at
Definition: twophase.c:151
TimestampTz prepared_at
Definition: xact.h:358
static int TwoPhaseFilePath(char *path, TransactionId xid)
Definition: twophase.c:961
bool RecoveryInProgress(void)
Definition: xlog.c:6333
#define LSN_FORMAT_ARGS(lsn)
Definition: xlogdefs.h:43
#define XLogRecPtrIsInvalid(r)
Definition: xlogdefs.h:29
bool reachedConsistency
Definition: xlogrecovery.c:295

References Assert, buf, DEBUG2, elog, ereport, errcode(), errcode_for_file_access(), errdetail(), errhint(), errmsg(), ERROR, TwoPhaseStateData::freeGXacts, GlobalTransactionData::gid, GlobalTransactionData::inredo, INVALID_PROC_NUMBER, InvalidRepOriginId, GlobalTransactionData::locking_backend, LSN_FORMAT_ARGS, LW_EXCLUSIVE, LWLockHeldByMeInMode(), max_prepared_xacts, MAXALIGN, MAXPGPATH, GlobalTransactionData::next, TwoPhaseStateData::numPrepXacts, GlobalTransactionData::ondisk, xl_xact_prepare::origin_lsn, GlobalTransactionData::owner, xl_xact_prepare::owner, GlobalTransactionData::prepare_end_lsn, GlobalTransactionData::prepare_start_lsn, GlobalTransactionData::prepared_at, xl_xact_prepare::prepared_at, TwoPhaseStateData::prepXacts, reachedConsistency, RecoveryInProgress(), replorigin_advance(), TwoPhaseFilePath(), TwoPhaseState, GlobalTransactionData::valid, WARNING, GlobalTransactionData::xid, xl_xact_prepare::xid, and XLogRecPtrIsInvalid.

Referenced by restoreTwoPhaseData(), and xact_redo().

◆ PrepareRedoRemove()

void PrepareRedoRemove ( TransactionId  xid,
bool  giveWarning 
)

Definition at line 2588 of file twophase.c.

2589 {
2590  GlobalTransaction gxact = NULL;
2591  int i;
2592  bool found = false;
2593 
2594  Assert(LWLockHeldByMeInMode(TwoPhaseStateLock, LW_EXCLUSIVE));
2596 
2597  for (i = 0; i < TwoPhaseState->numPrepXacts; i++)
2598  {
2599  gxact = TwoPhaseState->prepXacts[i];
2600 
2601  if (gxact->xid == xid)
2602  {
2603  Assert(gxact->inredo);
2604  found = true;
2605  break;
2606  }
2607  }
2608 
2609  /*
2610  * Just leave if there is nothing, this is expected during WAL replay.
2611  */
2612  if (!found)
2613  return;
2614 
2615  /*
2616  * And now we can clean up any files we may have left.
2617  */
2618  elog(DEBUG2, "removing 2PC data for transaction %u", xid);
2619  if (gxact->ondisk)
2620  RemoveTwoPhaseFile(xid, giveWarning);
2621  RemoveGXact(gxact);
2622 }

References Assert, DEBUG2, elog, i, GlobalTransactionData::inredo, LW_EXCLUSIVE, LWLockHeldByMeInMode(), TwoPhaseStateData::numPrepXacts, GlobalTransactionData::ondisk, TwoPhaseStateData::prepXacts, RecoveryInProgress(), RemoveGXact(), RemoveTwoPhaseFile(), TwoPhaseState, and GlobalTransactionData::xid.

Referenced by ProcessTwoPhaseBuffer(), and xact_redo().

◆ PrescanPreparedTransactions()

TransactionId PrescanPreparedTransactions ( TransactionId **  xids_p,
int *  nxids_p 
)

Definition at line 1969 of file twophase.c.

1970 {
1972  TransactionId origNextXid = XidFromFullTransactionId(nextXid);
1973  TransactionId result = origNextXid;
1974  TransactionId *xids = NULL;
1975  int nxids = 0;
1976  int allocsize = 0;
1977  int i;
1978 
1979  LWLockAcquire(TwoPhaseStateLock, LW_EXCLUSIVE);
1980  for (i = 0; i < TwoPhaseState->numPrepXacts; i++)
1981  {
1982  TransactionId xid;
1983  char *buf;
1985 
1986  Assert(gxact->inredo);
1987 
1988  xid = gxact->xid;
1989 
1990  buf = ProcessTwoPhaseBuffer(xid,
1991  gxact->prepare_start_lsn,
1992  gxact->ondisk, false, true);
1993 
1994  if (buf == NULL)
1995  continue;
1996 
1997  /*
1998  * OK, we think this file is valid. Incorporate xid into the
1999  * running-minimum result.
2000  */
2001  if (TransactionIdPrecedes(xid, result))
2002  result = xid;
2003 
2004  if (xids_p)
2005  {
2006  if (nxids == allocsize)
2007  {
2008  if (nxids == 0)
2009  {
2010  allocsize = 10;
2011  xids = palloc(allocsize * sizeof(TransactionId));
2012  }
2013  else
2014  {
2015  allocsize = allocsize * 2;
2016  xids = repalloc(xids, allocsize * sizeof(TransactionId));
2017  }
2018  }
2019  xids[nxids++] = xid;
2020  }
2021 
2022  pfree(buf);
2023  }
2024  LWLockRelease(TwoPhaseStateLock);
2025 
2026  if (xids_p)
2027  {
2028  *xids_p = xids;
2029  *nxids_p = nxids;
2030  }
2031 
2032  return result;
2033 }
void * repalloc(void *pointer, Size size)
Definition: mcxt.c:1541
void * palloc(Size size)
Definition: mcxt.c:1317
FullTransactionId nextXid
Definition: transam.h:220
bool TransactionIdPrecedes(TransactionId id1, TransactionId id2)
Definition: transam.c:280
#define XidFromFullTransactionId(x)
Definition: transam.h:48
static char * ProcessTwoPhaseBuffer(TransactionId xid, XLogRecPtr prepare_start_lsn, bool fromdisk, bool setParent, bool setNextXid)
Definition: twophase.c:2193
TransamVariablesData * TransamVariables
Definition: varsup.c:34

References Assert, buf, i, GlobalTransactionData::inredo, LW_EXCLUSIVE, LWLockAcquire(), LWLockRelease(), TransamVariablesData::nextXid, TwoPhaseStateData::numPrepXacts, GlobalTransactionData::ondisk, palloc(), pfree(), GlobalTransactionData::prepare_start_lsn, TwoPhaseStateData::prepXacts, ProcessTwoPhaseBuffer(), repalloc(), TransactionIdPrecedes(), TransamVariables, TwoPhaseState, GlobalTransactionData::xid, and XidFromFullTransactionId.

Referenced by StartupXLOG(), and xlog_redo().

◆ RecoverPreparedTransactions()

void RecoverPreparedTransactions ( void  )

Definition at line 2090 of file twophase.c.

2091 {
2092  int i;
2093 
2094  LWLockAcquire(TwoPhaseStateLock, LW_EXCLUSIVE);
2095  for (i = 0; i < TwoPhaseState->numPrepXacts; i++)
2096  {
2097  TransactionId xid;
2098  char *buf;
2100  char *bufptr;
2101  TwoPhaseFileHeader *hdr;
2102  TransactionId *subxids;
2103  const char *gid;
2104 
2105  xid = gxact->xid;
2106 
2107  /*
2108  * Reconstruct subtrans state for the transaction --- needed because
2109  * pg_subtrans is not preserved over a restart. Note that we are
2110  * linking all the subtransactions directly to the top-level XID;
2111  * there may originally have been a more complex hierarchy, but
2112  * there's no need to restore that exactly. It's possible that
2113  * SubTransSetParent has been set before, if the prepared transaction
2114  * generated xid assignment records.
2115  */
2116  buf = ProcessTwoPhaseBuffer(xid,
2117  gxact->prepare_start_lsn,
2118  gxact->ondisk, true, false);
2119  if (buf == NULL)
2120  continue;
2121 
2122  ereport(LOG,
2123  (errmsg("recovering prepared transaction %u from shared memory", xid)));
2124 
2125  hdr = (TwoPhaseFileHeader *) buf;
2126  Assert(TransactionIdEquals(hdr->xid, xid));
2127  bufptr = buf + MAXALIGN(sizeof(TwoPhaseFileHeader));
2128  gid = (const char *) bufptr;
2129  bufptr += MAXALIGN(hdr->gidlen);
2130  subxids = (TransactionId *) bufptr;
2131  bufptr += MAXALIGN(hdr->nsubxacts * sizeof(TransactionId));
2132  bufptr += MAXALIGN(hdr->ncommitrels * sizeof(RelFileLocator));
2133  bufptr += MAXALIGN(hdr->nabortrels * sizeof(RelFileLocator));
2134  bufptr += MAXALIGN(hdr->ncommitstats * sizeof(xl_xact_stats_item));
2135  bufptr += MAXALIGN(hdr->nabortstats * sizeof(xl_xact_stats_item));
2136  bufptr += MAXALIGN(hdr->ninvalmsgs * sizeof(SharedInvalidationMessage));
2137 
2138  /*
2139  * Recreate its GXACT and dummy PGPROC. But, check whether it was
2140  * added in redo and already has a shmem entry for it.
2141  */
2142  MarkAsPreparingGuts(gxact, xid, gid,
2143  hdr->prepared_at,
2144  hdr->owner, hdr->database);
2145 
2146  /* recovered, so reset the flag for entries generated by redo */
2147  gxact->inredo = false;
2148 
2149  GXactLoadSubxactData(gxact, hdr->nsubxacts, subxids);
2150  MarkAsPrepared(gxact, true);
2151 
2152  LWLockRelease(TwoPhaseStateLock);
2153 
2154  /*
2155  * Recover other state (notably locks) using resource managers.
2156  */
2158 
2159  /*
2160  * Release locks held by the standby process after we process each
2161  * prepared transaction. As a result, we don't need too many
2162  * additional locks at any one time.
2163  */
2164  if (InHotStandby)
2165  StandbyReleaseLockTree(xid, hdr->nsubxacts, subxids);
2166 
2167  /*
2168  * We're done with recovering this transaction. Clear MyLockedGxact,
2169  * like we do in PrepareTransaction() during normal operation.
2170  */
2172 
2173  pfree(buf);
2174 
2175  LWLockAcquire(TwoPhaseStateLock, LW_EXCLUSIVE);
2176  }
2177 
2178  LWLockRelease(TwoPhaseStateLock);
2179 }
void StandbyReleaseLockTree(TransactionId xid, int nsubxids, TransactionId *subxids)
Definition: standby.c:1091
Oid database
Definition: xact.h:357
static void GXactLoadSubxactData(GlobalTransaction gxact, int nsubxacts, TransactionId *children)
Definition: twophase.c:504
void PostPrepare_Twophase(void)
Definition: twophase.c:344
const TwoPhaseCallback twophase_recover_callbacks[TWOPHASE_RM_MAX_ID+1]
Definition: twophase_rmgr.c:24
#define InHotStandby
Definition: xlogutils.h:60

References Assert, buf, xl_xact_prepare::database, ereport, errmsg(), xl_xact_prepare::gidlen, GXactLoadSubxactData(), i, InHotStandby, GlobalTransactionData::inredo, LOG, LW_EXCLUSIVE, LWLockAcquire(), LWLockRelease(), MarkAsPrepared(), MarkAsPreparingGuts(), MAXALIGN, xl_xact_prepare::nabortrels, xl_xact_prepare::nabortstats, xl_xact_prepare::ncommitrels, xl_xact_prepare::ncommitstats, xl_xact_prepare::ninvalmsgs, xl_xact_prepare::nsubxacts, TwoPhaseStateData::numPrepXacts, GlobalTransactionData::ondisk, xl_xact_prepare::owner, pfree(), PostPrepare_Twophase(), GlobalTransactionData::prepare_start_lsn, xl_xact_prepare::prepared_at, TwoPhaseStateData::prepXacts, ProcessRecords(), ProcessTwoPhaseBuffer(), StandbyReleaseLockTree(), TransactionIdEquals, twophase_recover_callbacks, TwoPhaseState, GlobalTransactionData::xid, and xl_xact_prepare::xid.

Referenced by StartupXLOG().

◆ restoreTwoPhaseData()

void restoreTwoPhaseData ( void  )

Definition at line 1905 of file twophase.c.

1906 {
1907  DIR *cldir;
1908  struct dirent *clde;
1909 
1910  LWLockAcquire(TwoPhaseStateLock, LW_EXCLUSIVE);
1911  cldir = AllocateDir(TWOPHASE_DIR);
1912  while ((clde = ReadDir(cldir, TWOPHASE_DIR)) != NULL)
1913  {
1914  if (strlen(clde->d_name) == 16 &&
1915  strspn(clde->d_name, "0123456789ABCDEF") == 16)
1916  {
1917  TransactionId xid;
1918  FullTransactionId fxid;
1919  char *buf;
1920 
1921  fxid = FullTransactionIdFromU64(strtou64(clde->d_name, NULL, 16));
1922  xid = XidFromFullTransactionId(fxid);
1923 
1925  true, false, false);
1926  if (buf == NULL)
1927  continue;
1928 
1931  }
1932  }
1933  LWLockRelease(TwoPhaseStateLock);
1934  FreeDir(cldir);
1935 }
#define strtou64(str, endptr, base)
Definition: c.h:1289
struct dirent * ReadDir(DIR *dir, const char *dirname)
Definition: fd.c:2932
int FreeDir(DIR *dir)
Definition: fd.c:2984
DIR * AllocateDir(const char *dirname)
Definition: fd.c:2866
Definition: dirent.c:26
Definition: dirent.h:10
char d_name[MAX_PATH]
Definition: dirent.h:15
static FullTransactionId FullTransactionIdFromU64(uint64 value)
Definition: transam.h:81
void PrepareRedoAdd(char *buf, XLogRecPtr start_lsn, XLogRecPtr end_lsn, RepOriginId origin_id)
Definition: twophase.c:2486

References AllocateDir(), buf, dirent::d_name, FreeDir(), FullTransactionIdFromU64(), InvalidRepOriginId, InvalidXLogRecPtr, LW_EXCLUSIVE, LWLockAcquire(), LWLockRelease(), PrepareRedoAdd(), ProcessTwoPhaseBuffer(), ReadDir(), strtou64, TWOPHASE_DIR, and XidFromFullTransactionId.

Referenced by StartupXLOG().

◆ StandbyRecoverPreparedTransactions()

void StandbyRecoverPreparedTransactions ( void  )

Definition at line 2049 of file twophase.c.

2050 {
2051  int i;
2052 
2053  LWLockAcquire(TwoPhaseStateLock, LW_EXCLUSIVE);
2054  for (i = 0; i < TwoPhaseState->numPrepXacts; i++)
2055  {
2056  TransactionId xid;
2057  char *buf;
2059 
2060  Assert(gxact->inredo);
2061 
2062  xid = gxact->xid;
2063 
2064  buf = ProcessTwoPhaseBuffer(xid,
2065  gxact->prepare_start_lsn,
2066  gxact->ondisk, true, false);
2067  if (buf != NULL)
2068  pfree(buf);
2069  }
2070  LWLockRelease(TwoPhaseStateLock);
2071 }

References Assert, buf, i, GlobalTransactionData::inredo, LW_EXCLUSIVE, LWLockAcquire(), LWLockRelease(), TwoPhaseStateData::numPrepXacts, GlobalTransactionData::ondisk, pfree(), GlobalTransactionData::prepare_start_lsn, TwoPhaseStateData::prepXacts, ProcessTwoPhaseBuffer(), TwoPhaseState, and GlobalTransactionData::xid.

Referenced by StartupXLOG(), and xlog_redo().

◆ StandbyTransactionIdIsPrepared()

bool StandbyTransactionIdIsPrepared ( TransactionId  xid)

Definition at line 1475 of file twophase.c.

1476 {
1477  char *buf;
1478  TwoPhaseFileHeader *hdr;
1479  bool result;
1480 
1482 
1483  if (max_prepared_xacts <= 0)
1484  return false; /* nothing to do */
1485 
1486  /* Read and validate file */
1487  buf = ReadTwoPhaseFile(xid, true);
1488  if (buf == NULL)
1489  return false;
1490 
1491  /* Check header also */
1492  hdr = (TwoPhaseFileHeader *) buf;
1493  result = TransactionIdEquals(hdr->xid, xid);
1494  pfree(buf);
1495 
1496  return result;
1497 }
#define TransactionIdIsValid(xid)
Definition: transam.h:41

References Assert, buf, max_prepared_xacts, pfree(), ReadTwoPhaseFile(), TransactionIdEquals, TransactionIdIsValid, and xl_xact_prepare::xid.

Referenced by KnownAssignedXidsRemovePreceding(), and StandbyReleaseOldLocks().

◆ StartPrepare()

void StartPrepare ( GlobalTransaction  gxact)

Definition at line 1065 of file twophase.c.

1066 {
1067  PGPROC *proc = GetPGProcByNumber(gxact->pgprocno);
1068  TransactionId xid = gxact->xid;
1069  TwoPhaseFileHeader hdr;
1070  TransactionId *children;
1071  RelFileLocator *commitrels;
1072  RelFileLocator *abortrels;
1073  xl_xact_stats_item *abortstats = NULL;
1074  xl_xact_stats_item *commitstats = NULL;
1075  SharedInvalidationMessage *invalmsgs;
1076 
1077  /* Initialize linked list */
1078  records.head = palloc0(sizeof(StateFileChunk));
1079  records.head->len = 0;
1080  records.head->next = NULL;
1081 
1082  records.bytes_free = Max(sizeof(TwoPhaseFileHeader), 512);
1084 
1086  records.num_chunks = 1;
1087 
1088  records.total_len = 0;
1089 
1090  /* Create header */
1091  hdr.magic = TWOPHASE_MAGIC;
1092  hdr.total_len = 0; /* EndPrepare will fill this in */
1093  hdr.xid = xid;
1094  hdr.database = proc->databaseId;
1095  hdr.prepared_at = gxact->prepared_at;
1096  hdr.owner = gxact->owner;
1097  hdr.nsubxacts = xactGetCommittedChildren(&children);
1098  hdr.ncommitrels = smgrGetPendingDeletes(true, &commitrels);
1099  hdr.nabortrels = smgrGetPendingDeletes(false, &abortrels);
1100  hdr.ncommitstats =
1101  pgstat_get_transactional_drops(true, &commitstats);
1102  hdr.nabortstats =
1103  pgstat_get_transactional_drops(false, &abortstats);
1105  &hdr.initfileinval);
1106  hdr.gidlen = strlen(gxact->gid) + 1; /* Include '\0' */
1107  /* EndPrepare will fill the origin data, if necessary */
1109  hdr.origin_timestamp = 0;
1110 
1111  save_state_data(&hdr, sizeof(TwoPhaseFileHeader));
1112  save_state_data(gxact->gid, hdr.gidlen);
1113 
1114  /*
1115  * Add the additional info about subxacts, deletable files and cache
1116  * invalidation messages.
1117  */
1118  if (hdr.nsubxacts > 0)
1119  {
1120  save_state_data(children, hdr.nsubxacts * sizeof(TransactionId));
1121  /* While we have the child-xact data, stuff it in the gxact too */
1122  GXactLoadSubxactData(gxact, hdr.nsubxacts, children);
1123  }
1124  if (hdr.ncommitrels > 0)
1125  {
1126  save_state_data(commitrels, hdr.ncommitrels * sizeof(RelFileLocator));
1127  pfree(commitrels);
1128  }
1129  if (hdr.nabortrels > 0)
1130  {
1131  save_state_data(abortrels, hdr.nabortrels * sizeof(RelFileLocator));
1132  pfree(abortrels);
1133  }
1134  if (hdr.ncommitstats > 0)
1135  {
1136  save_state_data(commitstats,
1137  hdr.ncommitstats * sizeof(xl_xact_stats_item));
1138  pfree(commitstats);
1139  }
1140  if (hdr.nabortstats > 0)
1141  {
1142  save_state_data(abortstats,
1143  hdr.nabortstats * sizeof(xl_xact_stats_item));
1144  pfree(abortstats);
1145  }
1146  if (hdr.ninvalmsgs > 0)
1147  {
1148  save_state_data(invalmsgs,
1149  hdr.ninvalmsgs * sizeof(SharedInvalidationMessage));
1150  pfree(invalmsgs);
1151  }
1152 }
#define Max(x, y)
Definition: c.h:989
int xactGetCommittedInvalidationMessages(SharedInvalidationMessage **msgs, bool *RelcacheInitFileInval)
Definition: inval.c:882
void * palloc0(Size size)
Definition: mcxt.c:1347
int pgstat_get_transactional_drops(bool isCommit, xl_xact_stats_item **items)
Definition: pgstat_xact.c:272
int smgrGetPendingDeletes(bool forCommit, RelFileLocator **ptr)
Definition: storage.c:852
Oid databaseId
Definition: proc.h:207
uint32 bytes_free
Definition: twophase.c:1023
static void save_state_data(const void *data, uint32 len)
Definition: twophase.c:1037
int xactGetCommittedChildren(TransactionId **ptr)
Definition: xact.c:5777

References xllist::bytes_free, StateFileChunk::data, xl_xact_prepare::database, PGPROC::databaseId, GetPGProcByNumber, GlobalTransactionData::gid, xl_xact_prepare::gidlen, GXactLoadSubxactData(), xllist::head, xl_xact_prepare::initfileinval, InvalidXLogRecPtr, StateFileChunk::len, xl_xact_prepare::magic, Max, xl_xact_prepare::nabortrels, xl_xact_prepare::nabortstats, xl_xact_prepare::ncommitrels, xl_xact_prepare::ncommitstats, StateFileChunk::next, xl_xact_prepare::ninvalmsgs, xl_xact_prepare::nsubxacts, xllist::num_chunks, xl_xact_prepare::origin_lsn, xl_xact_prepare::origin_timestamp, GlobalTransactionData::owner, xl_xact_prepare::owner, palloc(), palloc0(), pfree(), GlobalTransactionData::pgprocno, pgstat_get_transactional_drops(), GlobalTransactionData::prepared_at, xl_xact_prepare::prepared_at, records, save_state_data(), smgrGetPendingDeletes(), xllist::tail, xllist::total_len, xl_xact_prepare::total_len, TWOPHASE_MAGIC, xactGetCommittedChildren(), xactGetCommittedInvalidationMessages(), GlobalTransactionData::xid, and xl_xact_prepare::xid.

Referenced by PrepareTransaction().

◆ TwoPhaseGetDummyProc()

PGPROC* TwoPhaseGetDummyProc ( TransactionId  xid,
bool  lock_held 
)

Definition at line 918 of file twophase.c.

919 {
920  GlobalTransaction gxact = TwoPhaseGetGXact(xid, lock_held);
921 
922  return GetPGProcByNumber(gxact->pgprocno);
923 }
static GlobalTransaction TwoPhaseGetGXact(TransactionId xid, bool lock_held)
Definition: twophase.c:800

References GetPGProcByNumber, GlobalTransactionData::pgprocno, and TwoPhaseGetGXact().

Referenced by lock_twophase_postcommit(), lock_twophase_recover(), and PostPrepare_Locks().

◆ TwoPhaseGetDummyProcNumber()

int TwoPhaseGetDummyProcNumber ( TransactionId  xid,
bool  lock_held 
)

Definition at line 903 of file twophase.c.

904 {
905  GlobalTransaction gxact = TwoPhaseGetGXact(xid, lock_held);
906 
907  return gxact->pgprocno;
908 }

References GlobalTransactionData::pgprocno, and TwoPhaseGetGXact().

Referenced by multixact_twophase_postcommit(), multixact_twophase_recover(), and PostPrepare_MultiXact().

◆ TwoPhaseGetXidByVirtualXID()

TransactionId TwoPhaseGetXidByVirtualXID ( VirtualTransactionId  vxid,
bool have_more 
)

Definition at line 852 of file twophase.c.

854 {
855  int i;
857 
859  LWLockAcquire(TwoPhaseStateLock, LW_SHARED);
860 
861  for (i = 0; i < TwoPhaseState->numPrepXacts; i++)
862  {
864  PGPROC *proc;
865  VirtualTransactionId proc_vxid;
866 
867  if (!gxact->valid)
868  continue;
869  proc = GetPGProcByNumber(gxact->pgprocno);
870  GET_VXID_FROM_PGPROC(proc_vxid, *proc);
871  if (VirtualTransactionIdEquals(vxid, proc_vxid))
872  {
873  /*
874  * Startup process sets proc->vxid.procNumber to
875  * INVALID_PROC_NUMBER.
876  */
877  Assert(!gxact->inredo);
878 
879  if (result != InvalidTransactionId)
880  {
881  *have_more = true;
882  break;
883  }
884  result = gxact->xid;
885  }
886  }
887 
888  LWLockRelease(TwoPhaseStateLock);
889 
890  return result;
891 }
#define VirtualTransactionIdIsValid(vxid)
Definition: lock.h:67
#define GET_VXID_FROM_PGPROC(vxid_dst, proc)
Definition: lock.h:77
#define VirtualTransactionIdEquals(vxid1, vxid2)
Definition: lock.h:71
#define InvalidTransactionId
Definition: transam.h:31

References Assert, GET_VXID_FROM_PGPROC, GetPGProcByNumber, i, GlobalTransactionData::inredo, InvalidTransactionId, LW_SHARED, LWLockAcquire(), LWLockRelease(), TwoPhaseStateData::numPrepXacts, GlobalTransactionData::pgprocno, TwoPhaseStateData::prepXacts, TwoPhaseState, GlobalTransactionData::valid, VirtualTransactionIdEquals, VirtualTransactionIdIsValid, and GlobalTransactionData::xid.

Referenced by XactLockForVirtualXact().

◆ TwoPhaseShmemInit()

void TwoPhaseShmemInit ( void  )

Definition at line 253 of file twophase.c.

254 {
255  bool found;
256 
257  TwoPhaseState = ShmemInitStruct("Prepared Transaction Table",
259  &found);
260  if (!IsUnderPostmaster)
261  {
262  GlobalTransaction gxacts;
263  int i;
264 
265  Assert(!found);
266  TwoPhaseState->freeGXacts = NULL;
268 
269  /*
270  * Initialize the linked list of free GlobalTransactionData structs
271  */
272  gxacts = (GlobalTransaction)
273  ((char *) TwoPhaseState +
274  MAXALIGN(offsetof(TwoPhaseStateData, prepXacts) +
276  for (i = 0; i < max_prepared_xacts; i++)
277  {
278  /* insert into linked list */
279  gxacts[i].next = TwoPhaseState->freeGXacts;
280  TwoPhaseState->freeGXacts = &gxacts[i];
281 
282  /* associate it with a PGPROC assigned by InitProcGlobal */
284  }
285  }
286  else
287  Assert(found);
288 }
bool IsUnderPostmaster
Definition: globals.c:119
#define GetNumberFromPGProc(proc)
Definition: proc.h:433
void * ShmemInitStruct(const char *name, Size size, bool *foundPtr)
Definition: shmem.c:387
PGPROC * PreparedXactProcs
Definition: proc.c:81
Size TwoPhaseShmemSize(void)
Definition: twophase.c:237
struct GlobalTransactionData * GlobalTransaction
Definition: twophase.h:26

References Assert, TwoPhaseStateData::freeGXacts, GetNumberFromPGProc, i, IsUnderPostmaster, max_prepared_xacts, MAXALIGN, GlobalTransactionData::next, TwoPhaseStateData::numPrepXacts, GlobalTransactionData::pgprocno, PreparedXactProcs, ShmemInitStruct(), TwoPhaseShmemSize(), and TwoPhaseState.

Referenced by CreateOrAttachShmemStructs().

◆ TwoPhaseShmemSize()

Size TwoPhaseShmemSize ( void  )

Definition at line 237 of file twophase.c.

238 {
239  Size size;
240 
241  /* Need the fixed struct, the array of pointers, and the GTD structs */
242  size = offsetof(TwoPhaseStateData, prepXacts);
244  sizeof(GlobalTransaction)));
245  size = MAXALIGN(size);
247  sizeof(GlobalTransactionData)));
248 
249  return size;
250 }
size_t Size
Definition: c.h:596
Size add_size(Size s1, Size s2)
Definition: shmem.c:493
Size mul_size(Size s1, Size s2)
Definition: shmem.c:510
static pg_noinline void Size size
Definition: slab.c:607

References add_size(), max_prepared_xacts, MAXALIGN, mul_size(), and size.

Referenced by CalculateShmemSize(), and TwoPhaseShmemInit().

◆ TwoPhaseTransactionGid()

void TwoPhaseTransactionGid ( Oid  subid,
TransactionId  xid,
char *  gid_res,
int  szgid 
)

Definition at line 2699 of file twophase.c.

2700 {
2701  Assert(OidIsValid(subid));
2702 
2703  if (!TransactionIdIsValid(xid))
2704  ereport(ERROR,
2705  (errcode(ERRCODE_PROTOCOL_VIOLATION),
2706  errmsg_internal("invalid two-phase transaction ID")));
2707 
2708  snprintf(gid_res, szgid, "pg_gid_%u_%u", subid, xid);
2709 }
#define OidIsValid(objectId)
Definition: c.h:766
int errmsg_internal(const char *fmt,...)
Definition: elog.c:1157
#define snprintf
Definition: port.h:238

References Assert, ereport, errcode(), errmsg_internal(), ERROR, OidIsValid, snprintf, and TransactionIdIsValid.

Referenced by apply_handle_commit_prepared(), apply_handle_prepare_internal(), apply_handle_rollback_prepared(), and IsTwoPhaseTransactionGidForSubid().

Variable Documentation

◆ max_prepared_xacts