mirror of
https://github.com/postgres/postgres.git
synced 2025-09-05 02:22:28 +03:00
Phase 2 pgindent run for v12.
Switch to 2.1 version of pg_bsd_indent. This formats multiline function declarations "correctly", that is with additional lines of parameter declarations indented to match where the first line's left parenthesis is. Discussion: https://postgr.es/m/CAEepm=0P3FeTXRcU5B2W3jv3PgRVZ-kGUXLGfd42FFhUROO3ug@mail.gmail.com
This commit is contained in:
@@ -430,9 +430,9 @@ ForgetPrivateRefCountEntry(PrivateRefCountEntry *ref)
|
||||
|
||||
|
||||
static Buffer ReadBuffer_common(SMgrRelation reln, char relpersistence,
|
||||
ForkNumber forkNum, BlockNumber blockNum,
|
||||
ReadBufferMode mode, BufferAccessStrategy strategy,
|
||||
bool *hit);
|
||||
ForkNumber forkNum, BlockNumber blockNum,
|
||||
ReadBufferMode mode, BufferAccessStrategy strategy,
|
||||
bool *hit);
|
||||
static bool PinBuffer(BufferDesc *buf, BufferAccessStrategy strategy);
|
||||
static void PinBuffer_Locked(BufferDesc *buf);
|
||||
static void UnpinBuffer(BufferDesc *buf, bool fixOwner);
|
||||
@@ -442,15 +442,15 @@ static int SyncOneBuffer(int buf_id, bool skip_recently_used, WritebackContext *
|
||||
static void WaitIO(BufferDesc *buf);
|
||||
static bool StartBufferIO(BufferDesc *buf, bool forInput);
|
||||
static void TerminateBufferIO(BufferDesc *buf, bool clear_dirty,
|
||||
uint32 set_flag_bits);
|
||||
uint32 set_flag_bits);
|
||||
static void shared_buffer_write_error_callback(void *arg);
|
||||
static void local_buffer_write_error_callback(void *arg);
|
||||
static BufferDesc *BufferAlloc(SMgrRelation smgr,
|
||||
char relpersistence,
|
||||
ForkNumber forkNum,
|
||||
BlockNumber blockNum,
|
||||
BufferAccessStrategy strategy,
|
||||
bool *foundPtr);
|
||||
char relpersistence,
|
||||
ForkNumber forkNum,
|
||||
BlockNumber blockNum,
|
||||
BufferAccessStrategy strategy,
|
||||
bool *foundPtr);
|
||||
static void FlushBuffer(BufferDesc *buf, SMgrRelation reln);
|
||||
static void AtProcExit_Buffers(int code, Datum arg);
|
||||
static void CheckForBufferLeaks(void);
|
||||
|
@@ -99,9 +99,9 @@ typedef struct BufferAccessStrategyData
|
||||
|
||||
/* Prototypes for internal functions */
|
||||
static BufferDesc *GetBufferFromRing(BufferAccessStrategy strategy,
|
||||
uint32 *buf_state);
|
||||
uint32 *buf_state);
|
||||
static void AddBufferToRing(BufferAccessStrategy strategy,
|
||||
BufferDesc *buf);
|
||||
BufferDesc *buf);
|
||||
|
||||
/*
|
||||
* ClockSweepTick - Helper routine for StrategyGetBuffer()
|
||||
|
@@ -308,14 +308,14 @@ static int FreeDesc(AllocateDesc *desc);
|
||||
static void AtProcExit_Files(int code, Datum arg);
|
||||
static void CleanupTempFiles(bool isCommit, bool isProcExit);
|
||||
static void RemovePgTempFilesInDir(const char *tmpdirname, bool missing_ok,
|
||||
bool unlink_all);
|
||||
bool unlink_all);
|
||||
static void RemovePgTempRelationFiles(const char *tsdirname);
|
||||
static void RemovePgTempRelationFilesInDbspace(const char *dbspacedirname);
|
||||
|
||||
static void walkdir(const char *path,
|
||||
void (*action) (const char *fname, bool isdir, int elevel),
|
||||
bool process_symlinks,
|
||||
int elevel);
|
||||
void (*action) (const char *fname, bool isdir, int elevel),
|
||||
bool process_symlinks,
|
||||
int elevel);
|
||||
#ifdef PG_FLUSH_DATA_WORKS
|
||||
static void pre_sync_fname(const char *fname, bool isdir, int elevel);
|
||||
#endif
|
||||
|
@@ -24,9 +24,9 @@
|
||||
#include "utils/memutils.h"
|
||||
|
||||
static void ResetUnloggedRelationsInTablespaceDir(const char *tsdirname,
|
||||
int op);
|
||||
int op);
|
||||
static void ResetUnloggedRelationsInDbspaceDir(const char *dbspacedirname,
|
||||
int op);
|
||||
int op);
|
||||
|
||||
typedef struct
|
||||
{
|
||||
|
@@ -105,12 +105,12 @@ static uint8 fsm_space_needed_to_cat(Size needed);
|
||||
static Size fsm_space_cat_to_avail(uint8 cat);
|
||||
|
||||
/* workhorse functions for various operations */
|
||||
static int fsm_set_and_search(Relation rel, FSMAddress addr, uint16 slot,
|
||||
uint8 newValue, uint8 minValue);
|
||||
static int fsm_set_and_search(Relation rel, FSMAddress addr, uint16 slot,
|
||||
uint8 newValue, uint8 minValue);
|
||||
static BlockNumber fsm_search(Relation rel, uint8 min_cat);
|
||||
static uint8 fsm_vacuum_page(Relation rel, FSMAddress addr,
|
||||
BlockNumber start, BlockNumber end,
|
||||
bool *eof);
|
||||
BlockNumber start, BlockNumber end,
|
||||
bool *eof);
|
||||
|
||||
|
||||
/******** Public API ********/
|
||||
|
@@ -98,7 +98,7 @@ static void dsm_cleanup_for_mmap(void);
|
||||
static void dsm_postmaster_shutdown(int code, Datum arg);
|
||||
static dsm_segment *dsm_create_descriptor(void);
|
||||
static bool dsm_control_segment_sane(dsm_control_header *control,
|
||||
Size mapped_size);
|
||||
Size mapped_size);
|
||||
static uint64 dsm_control_bytes_needed(uint32 nitems);
|
||||
|
||||
/* Has this backend initialized the dynamic shared memory system yet? */
|
||||
|
@@ -73,24 +73,24 @@
|
||||
|
||||
#ifdef USE_DSM_POSIX
|
||||
static bool dsm_impl_posix(dsm_op op, dsm_handle handle, Size request_size,
|
||||
void **impl_private, void **mapped_address,
|
||||
Size *mapped_size, int elevel);
|
||||
void **impl_private, void **mapped_address,
|
||||
Size *mapped_size, int elevel);
|
||||
static int dsm_impl_posix_resize(int fd, off_t size);
|
||||
#endif
|
||||
#ifdef USE_DSM_SYSV
|
||||
static bool dsm_impl_sysv(dsm_op op, dsm_handle handle, Size request_size,
|
||||
void **impl_private, void **mapped_address,
|
||||
Size *mapped_size, int elevel);
|
||||
void **impl_private, void **mapped_address,
|
||||
Size *mapped_size, int elevel);
|
||||
#endif
|
||||
#ifdef USE_DSM_WINDOWS
|
||||
static bool dsm_impl_windows(dsm_op op, dsm_handle handle, Size request_size,
|
||||
void **impl_private, void **mapped_address,
|
||||
Size *mapped_size, int elevel);
|
||||
void **impl_private, void **mapped_address,
|
||||
Size *mapped_size, int elevel);
|
||||
#endif
|
||||
#ifdef USE_DSM_MMAP
|
||||
static bool dsm_impl_mmap(dsm_op op, dsm_handle handle, Size request_size,
|
||||
void **impl_private, void **mapped_address,
|
||||
Size *mapped_size, int elevel);
|
||||
void **impl_private, void **mapped_address,
|
||||
Size *mapped_size, int elevel);
|
||||
#endif
|
||||
static int errcode_for_dynamic_shared_memory(void);
|
||||
|
||||
|
@@ -143,7 +143,7 @@ static void WaitEventAdjustWin32(WaitEventSet *set, WaitEvent *event);
|
||||
#endif
|
||||
|
||||
static inline int WaitEventSetWaitBlock(WaitEventSet *set, int cur_timeout,
|
||||
WaitEvent *occurred_events, int nevents);
|
||||
WaitEvent *occurred_events, int nevents);
|
||||
|
||||
/*
|
||||
* Initialize the process-local latch infrastructure.
|
||||
|
@@ -155,22 +155,22 @@ static void DisplayXidCache(void);
|
||||
/* Primitives for KnownAssignedXids array handling for standby */
|
||||
static void KnownAssignedXidsCompress(bool force);
|
||||
static void KnownAssignedXidsAdd(TransactionId from_xid, TransactionId to_xid,
|
||||
bool exclusive_lock);
|
||||
bool exclusive_lock);
|
||||
static bool KnownAssignedXidsSearch(TransactionId xid, bool remove);
|
||||
static bool KnownAssignedXidExists(TransactionId xid);
|
||||
static void KnownAssignedXidsRemove(TransactionId xid);
|
||||
static void KnownAssignedXidsRemoveTree(TransactionId xid, int nsubxids,
|
||||
TransactionId *subxids);
|
||||
TransactionId *subxids);
|
||||
static void KnownAssignedXidsRemovePreceding(TransactionId xid);
|
||||
static int KnownAssignedXidsGet(TransactionId *xarray, TransactionId xmax);
|
||||
static int KnownAssignedXidsGetAndSetXmin(TransactionId *xarray,
|
||||
TransactionId *xmin,
|
||||
TransactionId xmax);
|
||||
static int KnownAssignedXidsGetAndSetXmin(TransactionId *xarray,
|
||||
TransactionId *xmin,
|
||||
TransactionId xmax);
|
||||
static TransactionId KnownAssignedXidsGetOldestXmin(void);
|
||||
static void KnownAssignedXidsDisplay(int trace_level);
|
||||
static void KnownAssignedXidsReset(void);
|
||||
static inline void ProcArrayEndTransactionInternal(PGPROC *proc,
|
||||
PGXACT *pgxact, TransactionId latestXid);
|
||||
PGXACT *pgxact, TransactionId latestXid);
|
||||
static void ProcArrayGroupClearXid(PGPROC *proc, TransactionId latestXid);
|
||||
|
||||
/*
|
||||
|
@@ -144,14 +144,14 @@ struct shm_mq_handle
|
||||
|
||||
static void shm_mq_detach_internal(shm_mq *mq);
|
||||
static shm_mq_result shm_mq_send_bytes(shm_mq_handle *mqh, Size nbytes,
|
||||
const void *data, bool nowait, Size *bytes_written);
|
||||
const void *data, bool nowait, Size *bytes_written);
|
||||
static shm_mq_result shm_mq_receive_bytes(shm_mq_handle *mqh,
|
||||
Size bytes_needed, bool nowait, Size *nbytesp,
|
||||
void **datap);
|
||||
Size bytes_needed, bool nowait, Size *nbytesp,
|
||||
void **datap);
|
||||
static bool shm_mq_counterparty_gone(shm_mq *mq,
|
||||
BackgroundWorkerHandle *handle);
|
||||
BackgroundWorkerHandle *handle);
|
||||
static bool shm_mq_wait_internal(shm_mq *mq, PGPROC **ptr,
|
||||
BackgroundWorkerHandle *handle);
|
||||
BackgroundWorkerHandle *handle);
|
||||
static void shm_mq_inc_bytes_read(shm_mq *mq, Size n);
|
||||
static void shm_mq_inc_bytes_written(shm_mq *mq, Size n);
|
||||
static void shm_mq_detach_callback(dsm_segment *seg, Datum arg);
|
||||
|
@@ -43,7 +43,7 @@ int max_standby_streaming_delay = 30 * 1000;
|
||||
static HTAB *RecoveryLockLists;
|
||||
|
||||
static void ResolveRecoveryConflictWithVirtualXIDs(VirtualTransactionId *waitlist,
|
||||
ProcSignalReason reason);
|
||||
ProcSignalReason reason);
|
||||
static void SendRecoveryConflictWithBufferPin(ProcSignalReason reason);
|
||||
static XLogRecPtr LogCurrentRunningXacts(RunningTransactions CurrRunningXacts);
|
||||
static void LogAccessExclusiveLocks(int nlocks, xl_standby_lock *locks);
|
||||
|
@@ -79,15 +79,15 @@ typedef struct
|
||||
static bool DeadLockCheckRecurse(PGPROC *proc);
|
||||
static int TestConfiguration(PGPROC *startProc);
|
||||
static bool FindLockCycle(PGPROC *checkProc,
|
||||
EDGE *softEdges, int *nSoftEdges);
|
||||
EDGE *softEdges, int *nSoftEdges);
|
||||
static bool FindLockCycleRecurse(PGPROC *checkProc, int depth,
|
||||
EDGE *softEdges, int *nSoftEdges);
|
||||
EDGE *softEdges, int *nSoftEdges);
|
||||
static bool FindLockCycleRecurseMember(PGPROC *checkProc,
|
||||
PGPROC *checkProcLeader,
|
||||
int depth, EDGE *softEdges, int *nSoftEdges);
|
||||
PGPROC *checkProcLeader,
|
||||
int depth, EDGE *softEdges, int *nSoftEdges);
|
||||
static bool ExpandConstraints(EDGE *constraints, int nConstraints);
|
||||
static bool TopoSort(LOCK *lock, EDGE *constraints, int nConstraints,
|
||||
PGPROC **ordering);
|
||||
PGPROC **ordering);
|
||||
|
||||
#ifdef DEBUG_DEADLOCK
|
||||
static void PrintLockQueue(LOCK *lock, const char *info);
|
||||
|
@@ -211,7 +211,7 @@ static int FastPathLocalUseCount = 0;
|
||||
static bool FastPathGrantRelationLock(Oid relid, LOCKMODE lockmode);
|
||||
static bool FastPathUnGrantRelationLock(Oid relid, LOCKMODE lockmode);
|
||||
static bool FastPathTransferRelationLocks(LockMethod lockMethodTable,
|
||||
const LOCKTAG *locktag, uint32 hashcode);
|
||||
const LOCKTAG *locktag, uint32 hashcode);
|
||||
static PROCLOCK *FastPathGetRelationLockEntry(LOCALLOCK *locallock);
|
||||
|
||||
/*
|
||||
@@ -342,7 +342,7 @@ PROCLOCK_PRINT(const char *where, const PROCLOCK *proclockP)
|
||||
static uint32 proclock_hash(const void *key, Size keysize);
|
||||
static void RemoveLocalLock(LOCALLOCK *locallock);
|
||||
static PROCLOCK *SetupLockInTable(LockMethod lockMethodTable, PGPROC *proc,
|
||||
const LOCKTAG *locktag, uint32 hashcode, LOCKMODE lockmode);
|
||||
const LOCKTAG *locktag, uint32 hashcode, LOCKMODE lockmode);
|
||||
static void GrantLockLocal(LOCALLOCK *locallock, ResourceOwner owner);
|
||||
static void BeginStrongLockAcquire(LOCALLOCK *locallock, uint32 fasthashcode);
|
||||
static void FinishStrongLockAcquire(void);
|
||||
@@ -350,15 +350,15 @@ static void WaitOnLock(LOCALLOCK *locallock, ResourceOwner owner);
|
||||
static void ReleaseLockIfHeld(LOCALLOCK *locallock, bool sessionLock);
|
||||
static void LockReassignOwner(LOCALLOCK *locallock, ResourceOwner parent);
|
||||
static bool UnGrantLock(LOCK *lock, LOCKMODE lockmode,
|
||||
PROCLOCK *proclock, LockMethod lockMethodTable);
|
||||
PROCLOCK *proclock, LockMethod lockMethodTable);
|
||||
static void CleanUpLock(LOCK *lock, PROCLOCK *proclock,
|
||||
LockMethod lockMethodTable, uint32 hashcode,
|
||||
bool wakeupNeeded);
|
||||
LockMethod lockMethodTable, uint32 hashcode,
|
||||
bool wakeupNeeded);
|
||||
static void LockRefindAndRelease(LockMethod lockMethodTable, PGPROC *proc,
|
||||
LOCKTAG *locktag, LOCKMODE lockmode,
|
||||
bool decrement_strong_lock_count);
|
||||
LOCKTAG *locktag, LOCKMODE lockmode,
|
||||
bool decrement_strong_lock_count);
|
||||
static void GetSingleProcBlockerStatusData(PGPROC *blocked_proc,
|
||||
BlockedProcsData *data);
|
||||
BlockedProcsData *data);
|
||||
|
||||
|
||||
/*
|
||||
|
@@ -451,39 +451,39 @@ static uint32 predicatelock_hash(const void *key, Size keysize);
|
||||
static void SummarizeOldestCommittedSxact(void);
|
||||
static Snapshot GetSafeSnapshot(Snapshot snapshot);
|
||||
static Snapshot GetSerializableTransactionSnapshotInt(Snapshot snapshot,
|
||||
VirtualTransactionId *sourcevxid,
|
||||
int sourcepid);
|
||||
VirtualTransactionId *sourcevxid,
|
||||
int sourcepid);
|
||||
static bool PredicateLockExists(const PREDICATELOCKTARGETTAG *targettag);
|
||||
static bool GetParentPredicateLockTag(const PREDICATELOCKTARGETTAG *tag,
|
||||
PREDICATELOCKTARGETTAG *parent);
|
||||
PREDICATELOCKTARGETTAG *parent);
|
||||
static bool CoarserLockCovers(const PREDICATELOCKTARGETTAG *newtargettag);
|
||||
static void RemoveScratchTarget(bool lockheld);
|
||||
static void RestoreScratchTarget(bool lockheld);
|
||||
static void RemoveTargetIfNoLongerUsed(PREDICATELOCKTARGET *target,
|
||||
uint32 targettaghash);
|
||||
uint32 targettaghash);
|
||||
static void DeleteChildTargetLocks(const PREDICATELOCKTARGETTAG *newtargettag);
|
||||
static int MaxPredicateChildLocks(const PREDICATELOCKTARGETTAG *tag);
|
||||
static bool CheckAndPromotePredicateLockRequest(const PREDICATELOCKTARGETTAG *reqtag);
|
||||
static void DecrementParentLocks(const PREDICATELOCKTARGETTAG *targettag);
|
||||
static void CreatePredicateLock(const PREDICATELOCKTARGETTAG *targettag,
|
||||
uint32 targettaghash,
|
||||
SERIALIZABLEXACT *sxact);
|
||||
uint32 targettaghash,
|
||||
SERIALIZABLEXACT *sxact);
|
||||
static void DeleteLockTarget(PREDICATELOCKTARGET *target, uint32 targettaghash);
|
||||
static bool TransferPredicateLocksToNewTarget(PREDICATELOCKTARGETTAG oldtargettag,
|
||||
PREDICATELOCKTARGETTAG newtargettag,
|
||||
bool removeOld);
|
||||
PREDICATELOCKTARGETTAG newtargettag,
|
||||
bool removeOld);
|
||||
static void PredicateLockAcquire(const PREDICATELOCKTARGETTAG *targettag);
|
||||
static void DropAllPredicateLocksFromTable(Relation relation,
|
||||
bool transfer);
|
||||
bool transfer);
|
||||
static void SetNewSxactGlobalXmin(void);
|
||||
static void ClearOldPredicateLocks(void);
|
||||
static void ReleaseOneSerializableXact(SERIALIZABLEXACT *sxact, bool partial,
|
||||
bool summarize);
|
||||
bool summarize);
|
||||
static bool XidIsConcurrent(TransactionId xid);
|
||||
static void CheckTargetForConflictsIn(PREDICATELOCKTARGETTAG *targettag);
|
||||
static void FlagRWConflict(SERIALIZABLEXACT *reader, SERIALIZABLEXACT *writer);
|
||||
static void OnConflict_CheckForSerializationFailure(const SERIALIZABLEXACT *reader,
|
||||
SERIALIZABLEXACT *writer);
|
||||
SERIALIZABLEXACT *writer);
|
||||
static void CreateLocalPredicateLockHash(void);
|
||||
static void ReleasePredicateLocksLocal(void);
|
||||
|
||||
|
@@ -119,25 +119,25 @@ static MemoryContext MdCxt; /* context for all MdfdVec objects */
|
||||
|
||||
/* local routines */
|
||||
static void mdunlinkfork(RelFileNodeBackend rnode, ForkNumber forkNum,
|
||||
bool isRedo);
|
||||
bool isRedo);
|
||||
static MdfdVec *mdopen(SMgrRelation reln, ForkNumber forknum, int behavior);
|
||||
static void register_dirty_segment(SMgrRelation reln, ForkNumber forknum,
|
||||
MdfdVec *seg);
|
||||
MdfdVec *seg);
|
||||
static void register_unlink_segment(RelFileNodeBackend rnode, ForkNumber forknum,
|
||||
BlockNumber segno);
|
||||
BlockNumber segno);
|
||||
static void register_forget_request(RelFileNodeBackend rnode, ForkNumber forknum,
|
||||
BlockNumber segno);
|
||||
BlockNumber segno);
|
||||
static void _fdvec_resize(SMgrRelation reln,
|
||||
ForkNumber forknum,
|
||||
int nseg);
|
||||
ForkNumber forknum,
|
||||
int nseg);
|
||||
static char *_mdfd_segpath(SMgrRelation reln, ForkNumber forknum,
|
||||
BlockNumber segno);
|
||||
BlockNumber segno);
|
||||
static MdfdVec *_mdfd_openseg(SMgrRelation reln, ForkNumber forkno,
|
||||
BlockNumber segno, int oflags);
|
||||
BlockNumber segno, int oflags);
|
||||
static MdfdVec *_mdfd_getseg(SMgrRelation reln, ForkNumber forkno,
|
||||
BlockNumber blkno, bool skipFsync, int behavior);
|
||||
BlockNumber blkno, bool skipFsync, int behavior);
|
||||
static BlockNumber _mdnblocks(SMgrRelation reln, ForkNumber forknum,
|
||||
MdfdVec *seg);
|
||||
MdfdVec *seg);
|
||||
|
||||
|
||||
/*
|
||||
|
Reference in New Issue
Block a user