Unmark gen_random_uuid() function leakproof.
[pgsql.git] / src / include / storage / lock.h
blob787f3db06a9751f4c44418ea7d0d572e97ed26a8
1 /*-------------------------------------------------------------------------
3 * lock.h
4 * POSTGRES low-level lock mechanism
7 * Portions Copyright (c) 1996-2024, PostgreSQL Global Development Group
8 * Portions Copyright (c) 1994, Regents of the University of California
10 * src/include/storage/lock.h
12 *-------------------------------------------------------------------------
14 #ifndef LOCK_H_
15 #define LOCK_H_
17 #ifdef FRONTEND
18 #error "lock.h may not be included from frontend code"
19 #endif
21 #include "lib/ilist.h"
22 #include "storage/lockdefs.h"
23 #include "storage/lwlock.h"
24 #include "storage/procnumber.h"
25 #include "storage/shmem.h"
26 #include "utils/timestamp.h"
28 /* struct PGPROC is declared in proc.h, but must forward-reference it */
29 typedef struct PGPROC PGPROC;
31 /* GUC variables */
32 extern PGDLLIMPORT int max_locks_per_xact;
34 #ifdef LOCK_DEBUG
35 extern PGDLLIMPORT int Trace_lock_oidmin;
36 extern PGDLLIMPORT bool Trace_locks;
37 extern PGDLLIMPORT bool Trace_userlocks;
38 extern PGDLLIMPORT int Trace_lock_table;
39 extern PGDLLIMPORT bool Debug_deadlocks;
40 #endif /* LOCK_DEBUG */
44 * Top-level transactions are identified by VirtualTransactionIDs comprising
45 * PGPROC fields procNumber and lxid. For recovered prepared transactions, the
46 * LocalTransactionId is an ordinary XID; LOCKTAG_VIRTUALTRANSACTION never
47 * refers to that kind. These are guaranteed unique over the short term, but
48 * will be reused after a database restart or XID wraparound; hence they
49 * should never be stored on disk.
51 * Note that struct VirtualTransactionId can not be assumed to be atomically
52 * assignable as a whole. However, type LocalTransactionId is assumed to
53 * be atomically assignable, and the proc number doesn't change often enough
54 * to be a problem, so we can fetch or assign the two fields separately.
55 * We deliberately refrain from using the struct within PGPROC, to prevent
56 * coding errors from trying to use struct assignment with it; instead use
57 * GET_VXID_FROM_PGPROC().
59 typedef struct
61 ProcNumber procNumber; /* proc number of the PGPROC */
62 LocalTransactionId localTransactionId; /* lxid from PGPROC */
63 } VirtualTransactionId;
65 #define InvalidLocalTransactionId 0
66 #define LocalTransactionIdIsValid(lxid) ((lxid) != InvalidLocalTransactionId)
67 #define VirtualTransactionIdIsValid(vxid) \
68 (LocalTransactionIdIsValid((vxid).localTransactionId))
69 #define VirtualTransactionIdIsRecoveredPreparedXact(vxid) \
70 ((vxid).procNumber == INVALID_PROC_NUMBER)
71 #define VirtualTransactionIdEquals(vxid1, vxid2) \
72 ((vxid1).procNumber == (vxid2).procNumber && \
73 (vxid1).localTransactionId == (vxid2).localTransactionId)
74 #define SetInvalidVirtualTransactionId(vxid) \
75 ((vxid).procNumber = INVALID_PROC_NUMBER, \
76 (vxid).localTransactionId = InvalidLocalTransactionId)
77 #define GET_VXID_FROM_PGPROC(vxid_dst, proc) \
78 ((vxid_dst).procNumber = (proc).vxid.procNumber, \
79 (vxid_dst).localTransactionId = (proc).vxid.lxid)
81 /* MAX_LOCKMODES cannot be larger than the # of bits in LOCKMASK */
82 #define MAX_LOCKMODES 10
84 #define LOCKBIT_ON(lockmode) (1 << (lockmode))
85 #define LOCKBIT_OFF(lockmode) (~(1 << (lockmode)))
89 * This data structure defines the locking semantics associated with a
90 * "lock method". The semantics specify the meaning of each lock mode
91 * (by defining which lock modes it conflicts with).
92 * All of this data is constant and is kept in const tables.
94 * numLockModes -- number of lock modes (READ,WRITE,etc) that
95 * are defined in this lock method. Must be less than MAX_LOCKMODES.
97 * conflictTab -- this is an array of bitmasks showing lock
98 * mode conflicts. conflictTab[i] is a mask with the j-th bit
99 * turned on if lock modes i and j conflict. Lock modes are
100 * numbered 1..numLockModes; conflictTab[0] is unused.
102 * lockModeNames -- ID strings for debug printouts.
104 * trace_flag -- pointer to GUC trace flag for this lock method. (The
105 * GUC variable is not constant, but we use "const" here to denote that
106 * it can't be changed through this reference.)
108 typedef struct LockMethodData
110 int numLockModes;
111 const LOCKMASK *conflictTab;
112 const char *const *lockModeNames;
113 const bool *trace_flag;
114 } LockMethodData;
116 typedef const LockMethodData *LockMethod;
119 * Lock methods are identified by LOCKMETHODID. (Despite the declaration as
120 * uint16, we are constrained to 256 lockmethods by the layout of LOCKTAG.)
122 typedef uint16 LOCKMETHODID;
124 /* These identify the known lock methods */
125 #define DEFAULT_LOCKMETHOD 1
126 #define USER_LOCKMETHOD 2
129 * LOCKTAG is the key information needed to look up a LOCK item in the
130 * lock hashtable. A LOCKTAG value uniquely identifies a lockable object.
132 * The LockTagType enum defines the different kinds of objects we can lock.
133 * We can handle up to 256 different LockTagTypes.
135 typedef enum LockTagType
137 LOCKTAG_RELATION, /* whole relation */
138 LOCKTAG_RELATION_EXTEND, /* the right to extend a relation */
139 LOCKTAG_DATABASE_FROZEN_IDS, /* pg_database.datfrozenxid */
140 LOCKTAG_PAGE, /* one page of a relation */
141 LOCKTAG_TUPLE, /* one physical tuple */
142 LOCKTAG_TRANSACTION, /* transaction (for waiting for xact done) */
143 LOCKTAG_VIRTUALTRANSACTION, /* virtual transaction (ditto) */
144 LOCKTAG_SPECULATIVE_TOKEN, /* speculative insertion Xid and token */
145 LOCKTAG_OBJECT, /* non-relation database object */
146 LOCKTAG_USERLOCK, /* reserved for old contrib/userlock code */
147 LOCKTAG_ADVISORY, /* advisory user locks */
148 LOCKTAG_APPLY_TRANSACTION, /* transaction being applied on a logical
149 * replication subscriber */
150 } LockTagType;
152 #define LOCKTAG_LAST_TYPE LOCKTAG_APPLY_TRANSACTION
154 extern PGDLLIMPORT const char *const LockTagTypeNames[];
157 * The LOCKTAG struct is defined with malice aforethought to fit into 16
158 * bytes with no padding. Note that this would need adjustment if we were
159 * to widen Oid, BlockNumber, or TransactionId to more than 32 bits.
161 * We include lockmethodid in the locktag so that a single hash table in
162 * shared memory can store locks of different lockmethods.
164 typedef struct LOCKTAG
166 uint32 locktag_field1; /* a 32-bit ID field */
167 uint32 locktag_field2; /* a 32-bit ID field */
168 uint32 locktag_field3; /* a 32-bit ID field */
169 uint16 locktag_field4; /* a 16-bit ID field */
170 uint8 locktag_type; /* see enum LockTagType */
171 uint8 locktag_lockmethodid; /* lockmethod indicator */
172 } LOCKTAG;
175 * These macros define how we map logical IDs of lockable objects into
176 * the physical fields of LOCKTAG. Use these to set up LOCKTAG values,
177 * rather than accessing the fields directly. Note multiple eval of target!
180 /* ID info for a relation is DB OID + REL OID; DB OID = 0 if shared */
181 #define SET_LOCKTAG_RELATION(locktag,dboid,reloid) \
182 ((locktag).locktag_field1 = (dboid), \
183 (locktag).locktag_field2 = (reloid), \
184 (locktag).locktag_field3 = 0, \
185 (locktag).locktag_field4 = 0, \
186 (locktag).locktag_type = LOCKTAG_RELATION, \
187 (locktag).locktag_lockmethodid = DEFAULT_LOCKMETHOD)
189 /* same ID info as RELATION */
190 #define SET_LOCKTAG_RELATION_EXTEND(locktag,dboid,reloid) \
191 ((locktag).locktag_field1 = (dboid), \
192 (locktag).locktag_field2 = (reloid), \
193 (locktag).locktag_field3 = 0, \
194 (locktag).locktag_field4 = 0, \
195 (locktag).locktag_type = LOCKTAG_RELATION_EXTEND, \
196 (locktag).locktag_lockmethodid = DEFAULT_LOCKMETHOD)
198 /* ID info for frozen IDs is DB OID */
199 #define SET_LOCKTAG_DATABASE_FROZEN_IDS(locktag,dboid) \
200 ((locktag).locktag_field1 = (dboid), \
201 (locktag).locktag_field2 = 0, \
202 (locktag).locktag_field3 = 0, \
203 (locktag).locktag_field4 = 0, \
204 (locktag).locktag_type = LOCKTAG_DATABASE_FROZEN_IDS, \
205 (locktag).locktag_lockmethodid = DEFAULT_LOCKMETHOD)
207 /* ID info for a page is RELATION info + BlockNumber */
208 #define SET_LOCKTAG_PAGE(locktag,dboid,reloid,blocknum) \
209 ((locktag).locktag_field1 = (dboid), \
210 (locktag).locktag_field2 = (reloid), \
211 (locktag).locktag_field3 = (blocknum), \
212 (locktag).locktag_field4 = 0, \
213 (locktag).locktag_type = LOCKTAG_PAGE, \
214 (locktag).locktag_lockmethodid = DEFAULT_LOCKMETHOD)
216 /* ID info for a tuple is PAGE info + OffsetNumber */
217 #define SET_LOCKTAG_TUPLE(locktag,dboid,reloid,blocknum,offnum) \
218 ((locktag).locktag_field1 = (dboid), \
219 (locktag).locktag_field2 = (reloid), \
220 (locktag).locktag_field3 = (blocknum), \
221 (locktag).locktag_field4 = (offnum), \
222 (locktag).locktag_type = LOCKTAG_TUPLE, \
223 (locktag).locktag_lockmethodid = DEFAULT_LOCKMETHOD)
225 /* ID info for a transaction is its TransactionId */
226 #define SET_LOCKTAG_TRANSACTION(locktag,xid) \
227 ((locktag).locktag_field1 = (xid), \
228 (locktag).locktag_field2 = 0, \
229 (locktag).locktag_field3 = 0, \
230 (locktag).locktag_field4 = 0, \
231 (locktag).locktag_type = LOCKTAG_TRANSACTION, \
232 (locktag).locktag_lockmethodid = DEFAULT_LOCKMETHOD)
234 /* ID info for a virtual transaction is its VirtualTransactionId */
235 #define SET_LOCKTAG_VIRTUALTRANSACTION(locktag,vxid) \
236 ((locktag).locktag_field1 = (vxid).procNumber, \
237 (locktag).locktag_field2 = (vxid).localTransactionId, \
238 (locktag).locktag_field3 = 0, \
239 (locktag).locktag_field4 = 0, \
240 (locktag).locktag_type = LOCKTAG_VIRTUALTRANSACTION, \
241 (locktag).locktag_lockmethodid = DEFAULT_LOCKMETHOD)
244 * ID info for a speculative insert is TRANSACTION info +
245 * its speculative insert counter.
247 #define SET_LOCKTAG_SPECULATIVE_INSERTION(locktag,xid,token) \
248 ((locktag).locktag_field1 = (xid), \
249 (locktag).locktag_field2 = (token), \
250 (locktag).locktag_field3 = 0, \
251 (locktag).locktag_field4 = 0, \
252 (locktag).locktag_type = LOCKTAG_SPECULATIVE_TOKEN, \
253 (locktag).locktag_lockmethodid = DEFAULT_LOCKMETHOD)
256 * ID info for an object is DB OID + CLASS OID + OBJECT OID + SUBID
258 * Note: object ID has same representation as in pg_depend and
259 * pg_description, but notice that we are constraining SUBID to 16 bits.
260 * Also, we use DB OID = 0 for shared objects such as tablespaces.
262 #define SET_LOCKTAG_OBJECT(locktag,dboid,classoid,objoid,objsubid) \
263 ((locktag).locktag_field1 = (dboid), \
264 (locktag).locktag_field2 = (classoid), \
265 (locktag).locktag_field3 = (objoid), \
266 (locktag).locktag_field4 = (objsubid), \
267 (locktag).locktag_type = LOCKTAG_OBJECT, \
268 (locktag).locktag_lockmethodid = DEFAULT_LOCKMETHOD)
270 #define SET_LOCKTAG_ADVISORY(locktag,id1,id2,id3,id4) \
271 ((locktag).locktag_field1 = (id1), \
272 (locktag).locktag_field2 = (id2), \
273 (locktag).locktag_field3 = (id3), \
274 (locktag).locktag_field4 = (id4), \
275 (locktag).locktag_type = LOCKTAG_ADVISORY, \
276 (locktag).locktag_lockmethodid = USER_LOCKMETHOD)
279 * ID info for a remote transaction on a logical replication subscriber is: DB
280 * OID + SUBSCRIPTION OID + TRANSACTION ID + OBJID
282 #define SET_LOCKTAG_APPLY_TRANSACTION(locktag,dboid,suboid,xid,objid) \
283 ((locktag).locktag_field1 = (dboid), \
284 (locktag).locktag_field2 = (suboid), \
285 (locktag).locktag_field3 = (xid), \
286 (locktag).locktag_field4 = (objid), \
287 (locktag).locktag_type = LOCKTAG_APPLY_TRANSACTION, \
288 (locktag).locktag_lockmethodid = DEFAULT_LOCKMETHOD)
291 * Per-locked-object lock information:
293 * tag -- uniquely identifies the object being locked
294 * grantMask -- bitmask for all lock types currently granted on this object.
295 * waitMask -- bitmask for all lock types currently awaited on this object.
296 * procLocks -- list of PROCLOCK objects for this lock.
297 * waitProcs -- queue of processes waiting for this lock.
298 * requested -- count of each lock type currently requested on the lock
299 * (includes requests already granted!!).
300 * nRequested -- total requested locks of all types.
301 * granted -- count of each lock type currently granted on the lock.
302 * nGranted -- total granted locks of all types.
304 * Note: these counts count 1 for each backend. Internally to a backend,
305 * there may be multiple grabs on a particular lock, but this is not reflected
306 * into shared memory.
308 typedef struct LOCK
310 /* hash key */
311 LOCKTAG tag; /* unique identifier of lockable object */
313 /* data */
314 LOCKMASK grantMask; /* bitmask for lock types already granted */
315 LOCKMASK waitMask; /* bitmask for lock types awaited */
316 dlist_head procLocks; /* list of PROCLOCK objects assoc. with lock */
317 dclist_head waitProcs; /* list of PGPROC objects waiting on lock */
318 int requested[MAX_LOCKMODES]; /* counts of requested locks */
319 int nRequested; /* total of requested[] array */
320 int granted[MAX_LOCKMODES]; /* counts of granted locks */
321 int nGranted; /* total of granted[] array */
322 } LOCK;
324 #define LOCK_LOCKMETHOD(lock) ((LOCKMETHODID) (lock).tag.locktag_lockmethodid)
325 #define LOCK_LOCKTAG(lock) ((LockTagType) (lock).tag.locktag_type)
329 * We may have several different backends holding or awaiting locks
330 * on the same lockable object. We need to store some per-holder/waiter
331 * information for each such holder (or would-be holder). This is kept in
332 * a PROCLOCK struct.
334 * PROCLOCKTAG is the key information needed to look up a PROCLOCK item in the
335 * proclock hashtable. A PROCLOCKTAG value uniquely identifies the combination
336 * of a lockable object and a holder/waiter for that object. (We can use
337 * pointers here because the PROCLOCKTAG need only be unique for the lifespan
338 * of the PROCLOCK, and it will never outlive the lock or the proc.)
340 * Internally to a backend, it is possible for the same lock to be held
341 * for different purposes: the backend tracks transaction locks separately
342 * from session locks. However, this is not reflected in the shared-memory
343 * state: we only track which backend(s) hold the lock. This is OK since a
344 * backend can never block itself.
346 * The holdMask field shows the already-granted locks represented by this
347 * proclock. Note that there will be a proclock object, possibly with
348 * zero holdMask, for any lock that the process is currently waiting on.
349 * Otherwise, proclock objects whose holdMasks are zero are recycled
350 * as soon as convenient.
352 * releaseMask is workspace for LockReleaseAll(): it shows the locks due
353 * to be released during the current call. This must only be examined or
354 * set by the backend owning the PROCLOCK.
356 * Each PROCLOCK object is linked into lists for both the associated LOCK
357 * object and the owning PGPROC object. Note that the PROCLOCK is entered
358 * into these lists as soon as it is created, even if no lock has yet been
359 * granted. A PGPROC that is waiting for a lock to be granted will also be
360 * linked into the lock's waitProcs queue.
362 typedef struct PROCLOCKTAG
364 /* NB: we assume this struct contains no padding! */
365 LOCK *myLock; /* link to per-lockable-object information */
366 PGPROC *myProc; /* link to PGPROC of owning backend */
367 } PROCLOCKTAG;
369 typedef struct PROCLOCK
371 /* tag */
372 PROCLOCKTAG tag; /* unique identifier of proclock object */
374 /* data */
375 PGPROC *groupLeader; /* proc's lock group leader, or proc itself */
376 LOCKMASK holdMask; /* bitmask for lock types currently held */
377 LOCKMASK releaseMask; /* bitmask for lock types to be released */
378 dlist_node lockLink; /* list link in LOCK's list of proclocks */
379 dlist_node procLink; /* list link in PGPROC's list of proclocks */
380 } PROCLOCK;
382 #define PROCLOCK_LOCKMETHOD(proclock) \
383 LOCK_LOCKMETHOD(*((proclock).tag.myLock))
386 * Each backend also maintains a local hash table with information about each
387 * lock it is currently interested in. In particular the local table counts
388 * the number of times that lock has been acquired. This allows multiple
389 * requests for the same lock to be executed without additional accesses to
390 * shared memory. We also track the number of lock acquisitions per
391 * ResourceOwner, so that we can release just those locks belonging to a
392 * particular ResourceOwner.
394 * When holding a lock taken "normally", the lock and proclock fields always
395 * point to the associated objects in shared memory. However, if we acquired
396 * the lock via the fast-path mechanism, the lock and proclock fields are set
397 * to NULL, since there probably aren't any such objects in shared memory.
398 * (If the lock later gets promoted to normal representation, we may eventually
399 * update our locallock's lock/proclock fields after finding the shared
400 * objects.)
402 * Caution: a locallock object can be left over from a failed lock acquisition
403 * attempt. In this case its lock/proclock fields are untrustworthy, since
404 * the shared lock object is neither held nor awaited, and hence is available
405 * to be reclaimed. If nLocks > 0 then these pointers must either be valid or
406 * NULL, but when nLocks == 0 they should be considered garbage.
408 typedef struct LOCALLOCKTAG
410 LOCKTAG lock; /* identifies the lockable object */
411 LOCKMODE mode; /* lock mode for this table entry */
412 } LOCALLOCKTAG;
414 typedef struct LOCALLOCKOWNER
417 * Note: if owner is NULL then the lock is held on behalf of the session;
418 * otherwise it is held on behalf of my current transaction.
420 * Must use a forward struct reference to avoid circularity.
422 struct ResourceOwnerData *owner;
423 int64 nLocks; /* # of times held by this owner */
424 } LOCALLOCKOWNER;
426 typedef struct LOCALLOCK
428 /* tag */
429 LOCALLOCKTAG tag; /* unique identifier of locallock entry */
431 /* data */
432 uint32 hashcode; /* copy of LOCKTAG's hash value */
433 LOCK *lock; /* associated LOCK object, if any */
434 PROCLOCK *proclock; /* associated PROCLOCK object, if any */
435 int64 nLocks; /* total number of times lock is held */
436 int numLockOwners; /* # of relevant ResourceOwners */
437 int maxLockOwners; /* allocated size of array */
438 LOCALLOCKOWNER *lockOwners; /* dynamically resizable array */
439 bool holdsStrongLockCount; /* bumped FastPathStrongRelationLocks */
440 bool lockCleared; /* we read all sinval msgs for lock */
441 } LOCALLOCK;
443 #define LOCALLOCK_LOCKMETHOD(llock) ((llock).tag.lock.locktag_lockmethodid)
444 #define LOCALLOCK_LOCKTAG(llock) ((LockTagType) (llock).tag.lock.locktag_type)
448 * These structures hold information passed from lmgr internals to the lock
449 * listing user-level functions (in lockfuncs.c).
452 typedef struct LockInstanceData
454 LOCKTAG locktag; /* tag for locked object */
455 LOCKMASK holdMask; /* locks held by this PGPROC */
456 LOCKMODE waitLockMode; /* lock awaited by this PGPROC, if any */
457 VirtualTransactionId vxid; /* virtual transaction ID of this PGPROC */
458 TimestampTz waitStart; /* time at which this PGPROC started waiting
459 * for lock */
460 int pid; /* pid of this PGPROC */
461 int leaderPid; /* pid of group leader; = pid if no group */
462 bool fastpath; /* taken via fastpath? */
463 } LockInstanceData;
465 typedef struct LockData
467 int nelements; /* The length of the array */
468 LockInstanceData *locks; /* Array of per-PROCLOCK information */
469 } LockData;
471 typedef struct BlockedProcData
473 int pid; /* pid of a blocked PGPROC */
474 /* Per-PROCLOCK information about PROCLOCKs of the lock the pid awaits */
475 /* (these fields refer to indexes in BlockedProcsData.locks[]) */
476 int first_lock; /* index of first relevant LockInstanceData */
477 int num_locks; /* number of relevant LockInstanceDatas */
478 /* PIDs of PGPROCs that are ahead of "pid" in the lock's wait queue */
479 /* (these fields refer to indexes in BlockedProcsData.waiter_pids[]) */
480 int first_waiter; /* index of first preceding waiter */
481 int num_waiters; /* number of preceding waiters */
482 } BlockedProcData;
484 typedef struct BlockedProcsData
486 BlockedProcData *procs; /* Array of per-blocked-proc information */
487 LockInstanceData *locks; /* Array of per-PROCLOCK information */
488 int *waiter_pids; /* Array of PIDs of other blocked PGPROCs */
489 int nprocs; /* # of valid entries in procs[] array */
490 int maxprocs; /* Allocated length of procs[] array */
491 int nlocks; /* # of valid entries in locks[] array */
492 int maxlocks; /* Allocated length of locks[] array */
493 int npids; /* # of valid entries in waiter_pids[] array */
494 int maxpids; /* Allocated length of waiter_pids[] array */
495 } BlockedProcsData;
498 /* Result codes for LockAcquire() */
499 typedef enum
501 LOCKACQUIRE_NOT_AVAIL, /* lock not available, and dontWait=true */
502 LOCKACQUIRE_OK, /* lock successfully acquired */
503 LOCKACQUIRE_ALREADY_HELD, /* incremented count for lock already held */
504 LOCKACQUIRE_ALREADY_CLEAR, /* incremented count for lock already clear */
505 } LockAcquireResult;
507 /* Deadlock states identified by DeadLockCheck() */
508 typedef enum
510 DS_NOT_YET_CHECKED, /* no deadlock check has run yet */
511 DS_NO_DEADLOCK, /* no deadlock detected */
512 DS_SOFT_DEADLOCK, /* deadlock avoided by queue rearrangement */
513 DS_HARD_DEADLOCK, /* deadlock, no way out but ERROR */
514 DS_BLOCKED_BY_AUTOVACUUM, /* no deadlock; queue blocked by autovacuum
515 * worker */
516 } DeadLockState;
519 * The lockmgr's shared hash tables are partitioned to reduce contention.
520 * To determine which partition a given locktag belongs to, compute the tag's
521 * hash code with LockTagHashCode(), then apply one of these macros.
522 * NB: NUM_LOCK_PARTITIONS must be a power of 2!
524 #define LockHashPartition(hashcode) \
525 ((hashcode) % NUM_LOCK_PARTITIONS)
526 #define LockHashPartitionLock(hashcode) \
527 (&MainLWLockArray[LOCK_MANAGER_LWLOCK_OFFSET + \
528 LockHashPartition(hashcode)].lock)
529 #define LockHashPartitionLockByIndex(i) \
530 (&MainLWLockArray[LOCK_MANAGER_LWLOCK_OFFSET + (i)].lock)
533 * The deadlock detector needs to be able to access lockGroupLeader and
534 * related fields in the PGPROC, so we arrange for those fields to be protected
535 * by one of the lock hash partition locks. Since the deadlock detector
536 * acquires all such locks anyway, this makes it safe for it to access these
537 * fields without doing anything extra. To avoid contention as much as
538 * possible, we map different PGPROCs to different partition locks. The lock
539 * used for a given lock group is determined by the group leader's pgprocno.
541 #define LockHashPartitionLockByProc(leader_pgproc) \
542 LockHashPartitionLock(GetNumberFromPGProc(leader_pgproc))
545 * function prototypes
547 extern void LockManagerShmemInit(void);
548 extern Size LockManagerShmemSize(void);
549 extern void InitLockManagerAccess(void);
550 extern LockMethod GetLocksMethodTable(const LOCK *lock);
551 extern LockMethod GetLockTagsMethodTable(const LOCKTAG *locktag);
552 extern uint32 LockTagHashCode(const LOCKTAG *locktag);
553 extern bool DoLockModesConflict(LOCKMODE mode1, LOCKMODE mode2);
554 extern LockAcquireResult LockAcquire(const LOCKTAG *locktag,
555 LOCKMODE lockmode,
556 bool sessionLock,
557 bool dontWait);
558 extern LockAcquireResult LockAcquireExtended(const LOCKTAG *locktag,
559 LOCKMODE lockmode,
560 bool sessionLock,
561 bool dontWait,
562 bool reportMemoryError,
563 LOCALLOCK **locallockp);
564 extern void AbortStrongLockAcquire(void);
565 extern void MarkLockClear(LOCALLOCK *locallock);
566 extern bool LockRelease(const LOCKTAG *locktag,
567 LOCKMODE lockmode, bool sessionLock);
568 extern void LockReleaseAll(LOCKMETHODID lockmethodid, bool allLocks);
569 extern void LockReleaseSession(LOCKMETHODID lockmethodid);
570 extern void LockReleaseCurrentOwner(LOCALLOCK **locallocks, int nlocks);
571 extern void LockReassignCurrentOwner(LOCALLOCK **locallocks, int nlocks);
572 extern bool LockHeldByMe(const LOCKTAG *locktag,
573 LOCKMODE lockmode, bool orstronger);
574 #ifdef USE_ASSERT_CHECKING
575 extern HTAB *GetLockMethodLocalHash(void);
576 #endif
577 extern bool LockHasWaiters(const LOCKTAG *locktag,
578 LOCKMODE lockmode, bool sessionLock);
579 extern VirtualTransactionId *GetLockConflicts(const LOCKTAG *locktag,
580 LOCKMODE lockmode, int *countp);
581 extern void AtPrepare_Locks(void);
582 extern void PostPrepare_Locks(TransactionId xid);
583 extern bool LockCheckConflicts(LockMethod lockMethodTable,
584 LOCKMODE lockmode,
585 LOCK *lock, PROCLOCK *proclock);
586 extern void GrantLock(LOCK *lock, PROCLOCK *proclock, LOCKMODE lockmode);
587 extern void GrantAwaitedLock(void);
588 extern LOCALLOCK *GetAwaitedLock(void);
590 extern void RemoveFromWaitQueue(PGPROC *proc, uint32 hashcode);
591 extern LockData *GetLockStatusData(void);
592 extern BlockedProcsData *GetBlockerStatusData(int blocked_pid);
594 extern xl_standby_lock *GetRunningTransactionLocks(int *nlocks);
595 extern const char *GetLockmodeName(LOCKMETHODID lockmethodid, LOCKMODE mode);
597 extern void lock_twophase_recover(TransactionId xid, uint16 info,
598 void *recdata, uint32 len);
599 extern void lock_twophase_postcommit(TransactionId xid, uint16 info,
600 void *recdata, uint32 len);
601 extern void lock_twophase_postabort(TransactionId xid, uint16 info,
602 void *recdata, uint32 len);
603 extern void lock_twophase_standby_recover(TransactionId xid, uint16 info,
604 void *recdata, uint32 len);
606 extern DeadLockState DeadLockCheck(PGPROC *proc);
607 extern PGPROC *GetBlockingAutoVacuumPgproc(void);
608 extern void DeadLockReport(void) pg_attribute_noreturn();
609 extern void RememberSimpleDeadLock(PGPROC *proc1,
610 LOCKMODE lockmode,
611 LOCK *lock,
612 PGPROC *proc2);
613 extern void InitDeadLockChecking(void);
615 extern int LockWaiterCount(const LOCKTAG *locktag);
617 #ifdef LOCK_DEBUG
618 extern void DumpLocks(PGPROC *proc);
619 extern void DumpAllLocks(void);
620 #endif
622 /* Lock a VXID (used to wait for a transaction to finish) */
623 extern void VirtualXactLockTableInsert(VirtualTransactionId vxid);
624 extern void VirtualXactLockTableCleanup(void);
625 extern bool VirtualXactLock(VirtualTransactionId vxid, bool wait);
627 #endif /* LOCK_H_ */