aboutsummaryrefslogtreecommitdiff
path: root/src/include/storage
diff options
context:
space:
mode:
Diffstat (limited to 'src/include/storage')
-rw-r--r--src/include/storage/buf_internals.h18
-rw-r--r--src/include/storage/bufmgr.h4
-rw-r--r--src/include/storage/bufpage.h12
-rw-r--r--src/include/storage/ipc.h13
-rw-r--r--src/include/storage/itemid.h6
-rw-r--r--src/include/storage/itemptr.h4
-rw-r--r--src/include/storage/large_object.h9
-rw-r--r--src/include/storage/lmgr.h14
-rw-r--r--src/include/storage/lock.h39
-rw-r--r--src/include/storage/proc.h17
-rw-r--r--src/include/storage/relfilenode.h8
-rw-r--r--src/include/storage/shmem.h8
-rw-r--r--src/include/storage/sinvaladt.h5
-rw-r--r--src/include/storage/smgr.h12
-rw-r--r--src/include/storage/spin.h3
15 files changed, 91 insertions, 81 deletions
diff --git a/src/include/storage/buf_internals.h b/src/include/storage/buf_internals.h
index 051381bec68..b795d65fb20 100644
--- a/src/include/storage/buf_internals.h
+++ b/src/include/storage/buf_internals.h
@@ -7,7 +7,7 @@
* Portions Copyright (c) 1996-2001, PostgreSQL Global Development Group
* Portions Copyright (c) 1994, Regents of the University of California
*
- * $Id: buf_internals.h,v 1.47 2001/01/24 19:43:27 momjian Exp $
+ * $Id: buf_internals.h,v 1.48 2001/03/22 04:01:05 momjian Exp $
*
*-------------------------------------------------------------------------
*/
@@ -43,7 +43,7 @@ typedef bits16 BufFlags;
typedef struct buftag
{
- RelFileNode rnode;
+ RelFileNode rnode;
BlockNumber blockNum; /* blknum relative to begin of reln */
} BufferTag;
@@ -69,7 +69,7 @@ typedef struct bufblindid
{
char dbname[NAMEDATALEN]; /* name of db in which buf belongs */
char relname[NAMEDATALEN]; /* name of reln */
-} BufferBlindId;
+} BufferBlindId;
/*
* BufferDesc -- shared buffer cache metadata for a single
@@ -96,7 +96,7 @@ typedef struct sbufdesc
BufFlags flags; /* see bit definitions above */
unsigned refcount; /* # of times buffer is pinned */
- slock_t io_in_progress_lock; /* to block for I/O to complete */
+ slock_t io_in_progress_lock; /* to block for I/O to complete */
slock_t cntx_lock; /* to lock access to page context */
unsigned r_locks; /* # of shared locks */
@@ -108,12 +108,12 @@ typedef struct sbufdesc
BufferBlindId blind; /* was used to support blind write */
/*
- * When we can't delete item from page (someone else has buffer pinned)
- * we mark buffer for cleanup by specifying appropriate for buffer
- * content cleanup function. Buffer will be cleaned up from release
- * buffer functions.
+ * When we can't delete item from page (someone else has buffer
+ * pinned) we mark buffer for cleanup by specifying appropriate for
+ * buffer content cleanup function. Buffer will be cleaned up from
+ * release buffer functions.
*/
- void (*CleanupFunc)(Buffer);
+ void (*CleanupFunc) (Buffer);
} BufferDesc;
#define BufferDescriptorGetBuffer(bdesc) ((bdesc)->buf_id + 1)
diff --git a/src/include/storage/bufmgr.h b/src/include/storage/bufmgr.h
index 70f648931d7..fc76f9fe4c5 100644
--- a/src/include/storage/bufmgr.h
+++ b/src/include/storage/bufmgr.h
@@ -7,7 +7,7 @@
* Portions Copyright (c) 1996-2001, PostgreSQL Global Development Group
* Portions Copyright (c) 1994, Regents of the University of California
*
- * $Id: bufmgr.h,v 1.49 2001/01/24 19:43:27 momjian Exp $
+ * $Id: bufmgr.h,v 1.50 2001/03/22 04:01:05 momjian Exp $
*
*-------------------------------------------------------------------------
*/
@@ -192,7 +192,7 @@ extern void LockBuffer(Buffer buffer, int mode);
extern void AbortBufferIO(void);
extern bool BufferIsUpdatable(Buffer buffer);
-extern void MarkBufferForCleanup(Buffer buffer, void (*CleanupFunc)(Buffer));
+extern void MarkBufferForCleanup(Buffer buffer, void (*CleanupFunc) (Buffer));
extern void BufmgrCommit(void);
extern void BufferSync(void);
diff --git a/src/include/storage/bufpage.h b/src/include/storage/bufpage.h
index 07a5f2447ce..9dd956d3081 100644
--- a/src/include/storage/bufpage.h
+++ b/src/include/storage/bufpage.h
@@ -7,7 +7,7 @@
* Portions Copyright (c) 1996-2001, PostgreSQL Global Development Group
* Portions Copyright (c) 1994, Regents of the University of California
*
- * $Id: bufpage.h,v 1.40 2001/02/21 19:07:04 momjian Exp $
+ * $Id: bufpage.h,v 1.41 2001/03/22 04:01:05 momjian Exp $
*
*-------------------------------------------------------------------------
*/
@@ -118,12 +118,12 @@ typedef OpaqueData *Opaque;
*/
typedef struct PageHeaderData
{
- /* XXX LSN is member of *any* block, not */
- /* only page-organized - 'll change later */
+ /* XXX LSN is member of *any* block, not */
+ /* only page-organized - 'll change later */
XLogRecPtr pd_lsn; /* LSN: next byte after last byte of xlog */
- /* record for last change of this page */
+ /* record for last change of this page */
StartUpID pd_sui; /* SUI of last changes (currently it's */
- /* used by heap AM only) */
+ /* used by heap AM only) */
LocationIndex pd_lower; /* offset to start of free space */
LocationIndex pd_upper; /* offset to end of free space */
@@ -319,7 +319,7 @@ extern OffsetNumber PageAddItem(Page page, Item item, Size size,
OffsetNumber offsetNumber, ItemIdFlags flags);
extern Page PageGetTempPage(Page page, Size specialSize);
extern void PageRestoreTempPage(Page tempPage, Page oldPage);
-extern int PageRepairFragmentation(Page page, OffsetNumber *unused);
+extern int PageRepairFragmentation(Page page, OffsetNumber *unused);
extern Size PageGetFreeSpace(Page page);
extern void PageIndexTupleDelete(Page page, OffsetNumber offset);
extern void IndexPageCleanup(Buffer buffer);
diff --git a/src/include/storage/ipc.h b/src/include/storage/ipc.h
index f1e1e6096cd..aa685fc8ff6 100644
--- a/src/include/storage/ipc.h
+++ b/src/include/storage/ipc.h
@@ -7,7 +7,7 @@
* Portions Copyright (c) 1996-2001, PostgreSQL Global Development Group
* Portions Copyright (c) 1994, Regents of the University of California
*
- * $Id: ipc.h,v 1.48 2001/03/13 01:17:06 tgl Exp $
+ * $Id: ipc.h,v 1.49 2001/03/22 04:01:05 momjian Exp $
*
* Some files that would normally need to include only sys/ipc.h must
* instead include this file because on Ultrix, sys/ipc.h is not designed
@@ -21,7 +21,7 @@
#include <sys/types.h>
#ifdef HAVE_SYS_IPC_H
#include <sys/ipc.h>
-#endif /* HAVE_SYS_IPC_H */
+#endif /* HAVE_SYS_IPC_H */
#ifndef HAVE_UNION_SEMUN
union semun
@@ -30,6 +30,7 @@ union semun
struct semid_ds *buf;
unsigned short *array;
};
+
#endif
/* generic IPC definitions */
@@ -94,8 +95,8 @@ extern void on_exit_reset(void);
extern void IpcInitKeyAssignment(int port);
extern IpcSemaphoreId IpcSemaphoreCreate(int numSems, int permission,
- int semStartValue,
- bool removeOnExit);
+ int semStartValue,
+ bool removeOnExit);
extern void IpcSemaphoreKill(IpcSemaphoreId semId);
extern void IpcSemaphoreLock(IpcSemaphoreId semId, int sem, bool interruptOK);
extern void IpcSemaphoreUnlock(IpcSemaphoreId semId, int sem);
@@ -103,12 +104,12 @@ extern bool IpcSemaphoreTryLock(IpcSemaphoreId semId, int sem);
extern int IpcSemaphoreGetValue(IpcSemaphoreId semId, int sem);
extern PGShmemHeader *IpcMemoryCreate(uint32 size, bool makePrivate,
- int permission);
+ int permission);
extern bool SharedMemoryIsInUse(IpcMemoryKey shmKey, IpcMemoryId shmId);
/* ipci.c */
extern void CreateSharedMemoryAndSemaphores(bool makePrivate,
- int maxBackends);
+ int maxBackends);
#endif /* IPC_H */
diff --git a/src/include/storage/itemid.h b/src/include/storage/itemid.h
index e50cf6e0ba5..68ebcfee502 100644
--- a/src/include/storage/itemid.h
+++ b/src/include/storage/itemid.h
@@ -7,7 +7,7 @@
* Portions Copyright (c) 1996-2001, PostgreSQL Global Development Group
* Portions Copyright (c) 1994, Regents of the University of California
*
- * $Id: itemid.h,v 1.15 2001/01/24 19:43:27 momjian Exp $
+ * $Id: itemid.h,v 1.16 2001/03/22 04:01:06 momjian Exp $
*
*-------------------------------------------------------------------------
*/
@@ -31,7 +31,7 @@ typedef ItemIdData *ItemId;
*/
#define LP_USED 0x01 /* this line pointer is being used */
-#define LP_DELETE 0x02 /* item is to be deleted */
+#define LP_DELETE 0x02 /* item is to be deleted */
#define ItemIdDeleted(itemId) \
(((itemId)->lp_flags & LP_DELETE) != 0)
@@ -40,7 +40,7 @@ typedef ItemIdData *ItemId;
* This bit may be passed to PageAddItem together with
* LP_USED & LP_DELETED bits to specify overwrite mode
*/
-#define OverwritePageMode 0x10
+#define OverwritePageMode 0x10
/*
* Item offsets, lengths, and flags are represented by these types when
diff --git a/src/include/storage/itemptr.h b/src/include/storage/itemptr.h
index 710db49af8c..5b2c715e01e 100644
--- a/src/include/storage/itemptr.h
+++ b/src/include/storage/itemptr.h
@@ -7,7 +7,7 @@
* Portions Copyright (c) 1996-2001, PostgreSQL Global Development Group
* Portions Copyright (c) 1994, Regents of the University of California
*
- * $Id: itemptr.h,v 1.16 2001/01/24 19:43:27 momjian Exp $
+ * $Id: itemptr.h,v 1.17 2001/03/22 04:01:06 momjian Exp $
*
*-------------------------------------------------------------------------
*/
@@ -30,7 +30,7 @@ typedef struct ItemPointerData
OffsetNumber ip_posid;
} ItemPointerData;
-#define SizeOfIptrData \
+#define SizeOfIptrData \
(offsetof(ItemPointerData, ip_posid) + sizeof(OffsetNumber))
typedef ItemPointerData *ItemPointer;
diff --git a/src/include/storage/large_object.h b/src/include/storage/large_object.h
index 146d6333f47..05d62331386 100644
--- a/src/include/storage/large_object.h
+++ b/src/include/storage/large_object.h
@@ -8,7 +8,7 @@
* Portions Copyright (c) 1996-2001, PostgreSQL Global Development Group
* Portions Copyright (c) 1994, Regents of the University of California
*
- * $Id: large_object.h,v 1.20 2001/01/24 19:43:27 momjian Exp $
+ * $Id: large_object.h,v 1.21 2001/03/22 04:01:07 momjian Exp $
*
*-------------------------------------------------------------------------
*/
@@ -27,10 +27,11 @@
* index_r holds an open-relation reference to pg_largeobject_loid_pn_index
*
* NOTE: before 7.1, heap_r and index_r held references to the separate
- * table and index of a specific large object. Now they all live in one rel.
+ * table and index of a specific large object. Now they all live in one rel.
*----------
*/
-typedef struct LargeObjectDesc {
+typedef struct LargeObjectDesc
+{
Oid id;
uint32 offset; /* current seek pointer */
int flags; /* locking info, etc */
@@ -58,7 +59,7 @@ typedef struct LargeObjectDesc {
* since clients will often be written to send data in power-of-2 blocks.
* This avoids unnecessary tuple updates caused by partial-page writes.
*/
-#define LOBLKSIZE (BLCKSZ / 4)
+#define LOBLKSIZE (BLCKSZ / 4)
/*
diff --git a/src/include/storage/lmgr.h b/src/include/storage/lmgr.h
index 5906445f37f..45af8bedede 100644
--- a/src/include/storage/lmgr.h
+++ b/src/include/storage/lmgr.h
@@ -7,7 +7,7 @@
* Portions Copyright (c) 1996-2001, PostgreSQL Global Development Group
* Portions Copyright (c) 1994, Regents of the University of California
*
- * $Id: lmgr.h,v 1.29 2001/02/22 23:02:33 momjian Exp $
+ * $Id: lmgr.h,v 1.30 2001/03/22 04:01:07 momjian Exp $
*
*-------------------------------------------------------------------------
*/
@@ -26,11 +26,13 @@
#define RowShareLock 2 /* SELECT FOR UPDATE */
#define RowExclusiveLock 3 /* INSERT, UPDATE, DELETE */
#define ShareLock 4 /* CREATE INDEX */
-#define ShareRowExclusiveLock 5 /* like EXCLUSIVE MODE, allows SHARE ROW */
-#define ExclusiveLock 6 /* blocks ROW SHARE/SELECT...FOR UPDATE */
-#define AccessExclusiveLock 7 /* ALTER TABLE, DROP TABLE, VACUUM, and
- * unqualified LOCK TABLE
- */
+#define ShareRowExclusiveLock 5 /* like EXCLUSIVE MODE, allows
+ * SHARE ROW */
+#define ExclusiveLock 6 /* blocks ROW SHARE/SELECT...FOR
+ * UPDATE */
+#define AccessExclusiveLock 7 /* ALTER TABLE, DROP TABLE,
+ * VACUUM, and unqualified LOCK
+ * TABLE */
extern LOCKMETHOD LockTableId;
diff --git a/src/include/storage/lock.h b/src/include/storage/lock.h
index af07e889350..3d5ddb70385 100644
--- a/src/include/storage/lock.h
+++ b/src/include/storage/lock.h
@@ -7,7 +7,7 @@
* Portions Copyright (c) 1996-2001, PostgreSQL Global Development Group
* Portions Copyright (c) 1994, Regents of the University of California
*
- * $Id: lock.h,v 1.47 2001/02/23 19:24:06 momjian Exp $
+ * $Id: lock.h,v 1.48 2001/03/22 04:01:07 momjian Exp $
*
*-------------------------------------------------------------------------
*/
@@ -33,12 +33,13 @@ typedef struct proc PROC;
extern SPINLOCK LockMgrLock;
#ifdef LOCK_DEBUG
-extern int Trace_lock_oidmin;
+extern int Trace_lock_oidmin;
extern bool Trace_locks;
extern bool Trace_userlocks;
-extern int Trace_lock_table;
+extern int Trace_lock_table;
extern bool Debug_deadlocks;
-#endif /* LOCK_DEBUG */
+
+#endif /* LOCK_DEBUG */
/* ----------------------
@@ -60,7 +61,7 @@ typedef int LOCKMODE;
typedef int LOCKMETHOD;
/* MAX_LOCKMODES cannot be larger than the # of bits in LOCKMASK */
-#define MAX_LOCKMODES 8
+#define MAX_LOCKMODES 8
/*
* MAX_LOCK_METHODS corresponds to the number of spin locks allocated in
@@ -87,7 +88,7 @@ typedef int LOCKMETHOD;
/*
* This is the control structure for a lock table. It
- * lives in shared memory. This information is the same
+ * lives in shared memory. This information is the same
* for all backends.
*
* lockmethod -- the handle used by the lock table's clients to
@@ -132,7 +133,7 @@ typedef struct LOCKMETHODTABLE
/*
* LOCKTAG is the key information needed to look up a LOCK item in the
- * lock hashtable. A LOCKTAG value uniquely identifies a lockable object.
+ * lock hashtable. A LOCKTAG value uniquely identifies a lockable object.
*/
typedef struct LOCKTAG
{
@@ -179,9 +180,10 @@ typedef struct LOCK
int waitMask; /* bitmask for lock types awaited */
SHM_QUEUE lockHolders; /* list of HOLDER objects assoc. with lock */
PROC_QUEUE waitProcs; /* list of PROC objects waiting on lock */
- int requested[MAX_LOCKMODES]; /* counts of requested locks */
+ int requested[MAX_LOCKMODES]; /* counts of requested
+ * locks */
int nRequested; /* total of requested[] array */
- int granted[MAX_LOCKMODES]; /* counts of granted locks */
+ int granted[MAX_LOCKMODES]; /* counts of granted locks */
int nGranted; /* total of granted[] array */
} LOCK;
@@ -208,13 +210,13 @@ typedef struct LOCK
* with per-transaction locks obtained by the same backend.
*
* The holding[] array counts the granted locks (of each type) represented
- * by this holder. Note that there will be a holder object, possibly with
+ * by this holder. Note that there will be a holder object, possibly with
* zero holding[], for any lock that the process is currently waiting on.
* Otherwise, holder objects whose counts have gone to zero are recycled
* as soon as convenient.
*
* Each HOLDER object is linked into lists for both the associated LOCK object
- * and the owning PROC object. Note that the HOLDER is entered into these
+ * and the owning PROC object. Note that the HOLDER is entered into these
* lists as soon as it is created, even if no lock has yet been granted.
* A PROC that is waiting for a lock to be granted will also be linked into
* the lock's waitProcs queue.
@@ -232,7 +234,7 @@ typedef struct HOLDER
HOLDERTAG tag; /* unique identifier of holder object */
/* data */
- int holding[MAX_LOCKMODES]; /* count of locks currently held */
+ int holding[MAX_LOCKMODES]; /* count of locks currently held */
int nHolding; /* total of holding[] array */
SHM_QUEUE lockLink; /* list link for lock's list of holders */
SHM_QUEUE procLink; /* list link for process's list of holders */
@@ -261,15 +263,15 @@ extern LOCKMETHOD LockMethodTableInit(char *tabName, LOCKMASK *conflictsP,
int *prioP, int numModes, int maxBackends);
extern LOCKMETHOD LockMethodTableRename(LOCKMETHOD lockmethod);
extern bool LockAcquire(LOCKMETHOD lockmethod, LOCKTAG *locktag,
- TransactionId xid, LOCKMODE lockmode);
+ TransactionId xid, LOCKMODE lockmode);
extern bool LockRelease(LOCKMETHOD lockmethod, LOCKTAG *locktag,
- TransactionId xid, LOCKMODE lockmode);
+ TransactionId xid, LOCKMODE lockmode);
extern bool LockReleaseAll(LOCKMETHOD lockmethod, PROC *proc,
- bool allxids, TransactionId xid);
+ bool allxids, TransactionId xid);
extern int LockCheckConflicts(LOCKMETHODTABLE *lockMethodTable,
- LOCKMODE lockmode,
- LOCK *lock, HOLDER *holder, PROC *proc,
- int *myHolding);
+ LOCKMODE lockmode,
+ LOCK *lock, HOLDER *holder, PROC *proc,
+ int *myHolding);
extern void GrantLock(LOCK *lock, HOLDER *holder, LOCKMODE lockmode);
extern void RemoveFromWaitQueue(PROC *proc);
extern int LockShmemSize(int maxBackends);
@@ -279,6 +281,7 @@ extern void InitDeadLockChecking(void);
#ifdef LOCK_DEBUG
extern void DumpLocks(void);
extern void DumpAllLocks(void);
+
#endif
#endif /* LOCK_H */
diff --git a/src/include/storage/proc.h b/src/include/storage/proc.h
index 6290e83d50f..72e2aafd425 100644
--- a/src/include/storage/proc.h
+++ b/src/include/storage/proc.h
@@ -7,7 +7,7 @@
* Portions Copyright (c) 1996-2001, PostgreSQL Global Development Group
* Portions Copyright (c) 1994, Regents of the University of California
*
- * $Id: proc.h,v 1.40 2001/02/26 00:50:08 tgl Exp $
+ * $Id: proc.h,v 1.41 2001/03/22 04:01:08 momjian Exp $
*
*-------------------------------------------------------------------------
*/
@@ -18,7 +18,7 @@
#include "storage/lock.h"
/* configurable option */
-extern int DeadlockTimeout;
+extern int DeadlockTimeout;
typedef struct
{
@@ -50,9 +50,10 @@ struct proc
* were starting our xact: vacuum must not
* remove tuples deleted by xid >= xmin ! */
- /* XLOG location of first XLOG record written by this backend's current
- * transaction. If backend is not in a transaction or hasn't yet modified
- * anything, logRec.xrecoff is zero.
+ /*
+ * XLOG location of first XLOG record written by this backend's
+ * current transaction. If backend is not in a transaction or hasn't
+ * yet modified anything, logRec.xrecoff is zero.
*/
XLogRecPtr logRec;
@@ -68,8 +69,8 @@ struct proc
Oid databaseId; /* OID of database this backend is using */
short sLocks[MAX_SPINS]; /* Spin lock stats */
- SHM_QUEUE procHolders; /* list of HOLDER objects for locks held or
- * awaited by this backend */
+ SHM_QUEUE procHolders; /* list of HOLDER objects for locks held
+ * or awaited by this backend */
};
/* NOTE: "typedef struct proc PROC" appears in storage/lock.h. */
@@ -132,7 +133,7 @@ extern bool ProcRemove(int pid);
extern void ProcQueueInit(PROC_QUEUE *queue);
extern int ProcSleep(LOCKMETHODTABLE *lockMethodTable, LOCKMODE lockmode,
- LOCK *lock, HOLDER *holder);
+ LOCK *lock, HOLDER *holder);
extern PROC *ProcWakeup(PROC *proc, int errType);
extern void ProcLockWakeup(LOCKMETHODTABLE *lockMethodTable, LOCK *lock);
extern void ProcReleaseSpins(PROC *proc);
diff --git a/src/include/storage/relfilenode.h b/src/include/storage/relfilenode.h
index e4f07e9ac68..c53dea8f399 100644
--- a/src/include/storage/relfilenode.h
+++ b/src/include/storage/relfilenode.h
@@ -11,12 +11,12 @@
*/
typedef struct RelFileNode
{
- Oid tblNode; /* tablespace */
- Oid relNode; /* relation */
+ Oid tblNode; /* tablespace */
+ Oid relNode; /* relation */
} RelFileNode;
-#define RelFileNodeEquals(node1, node2) \
+#define RelFileNodeEquals(node1, node2) \
((node1).relNode == (node2).relNode && \
(node1).tblNode == (node2).tblNode)
-#endif /* RELFILENODE_H */
+#endif /* RELFILENODE_H */
diff --git a/src/include/storage/shmem.h b/src/include/storage/shmem.h
index 3331f117cc7..04c8bbaf418 100644
--- a/src/include/storage/shmem.h
+++ b/src/include/storage/shmem.h
@@ -7,7 +7,7 @@
* Portions Copyright (c) 1996-2001, PostgreSQL Global Development Group
* Portions Copyright (c) 1994, Regents of the University of California
*
- * $Id: shmem.h,v 1.27 2001/02/22 18:39:20 momjian Exp $
+ * $Id: shmem.h,v 1.28 2001/03/22 04:01:09 momjian Exp $
*
*-------------------------------------------------------------------------
*/
@@ -28,8 +28,8 @@
*/
typedef unsigned long SHMEM_OFFSET;
-#define INVALID_OFFSET (-1)
-#define BAD_LOCATION (-1)
+#define INVALID_OFFSET (-1)
+#define BAD_LOCATION (-1)
/*
* Start of the primary shared memory region, in this process' address space.
@@ -102,7 +102,7 @@ extern void SHMQueueElemInit(SHM_QUEUE *queue);
extern void SHMQueueDelete(SHM_QUEUE *queue);
extern void SHMQueueInsertBefore(SHM_QUEUE *queue, SHM_QUEUE *elem);
extern Pointer SHMQueueNext(SHM_QUEUE *queue, SHM_QUEUE *curElem,
- Size linkOffset);
+ Size linkOffset);
extern bool SHMQueueEmpty(SHM_QUEUE *queue);
#endif /* SHMEM_H */
diff --git a/src/include/storage/sinvaladt.h b/src/include/storage/sinvaladt.h
index 074e37eb17a..22b073350df 100644
--- a/src/include/storage/sinvaladt.h
+++ b/src/include/storage/sinvaladt.h
@@ -7,7 +7,7 @@
* Portions Copyright (c) 1996-2001, PostgreSQL Global Development Group
* Portions Copyright (c) 1994, Regents of the University of California
*
- * $Id: sinvaladt.h,v 1.25 2001/01/24 19:43:28 momjian Exp $
+ * $Id: sinvaladt.h,v 1.26 2001/03/22 04:01:09 momjian Exp $
*
*-------------------------------------------------------------------------
*/
@@ -89,7 +89,8 @@ typedef struct SISeg
*/
int minMsgNum; /* oldest message still needed */
int maxMsgNum; /* next message number to be assigned */
- int lastBackend; /* index of last active procState entry, +1 */
+ int lastBackend; /* index of last active procState entry,
+ * +1 */
int maxBackends; /* size of procState array */
/*
diff --git a/src/include/storage/smgr.h b/src/include/storage/smgr.h
index 58f11719991..34892040cc5 100644
--- a/src/include/storage/smgr.h
+++ b/src/include/storage/smgr.h
@@ -7,7 +7,7 @@
* Portions Copyright (c) 1996-2001, PostgreSQL Global Development Group
* Portions Copyright (c) 1994, Regents of the University of California
*
- * $Id: smgr.h,v 1.27 2001/01/24 19:43:28 momjian Exp $
+ * $Id: smgr.h,v 1.28 2001/03/22 04:01:09 momjian Exp $
*
*-------------------------------------------------------------------------
*/
@@ -38,9 +38,9 @@ extern int smgrwrite(int16 which, Relation reln, BlockNumber blocknum,
extern int smgrflush(int16 which, Relation reln, BlockNumber blocknum,
char *buffer);
extern int smgrblindwrt(int16 which, RelFileNode rnode,
- BlockNumber blkno, char *buffer, bool dofsync);
+ BlockNumber blkno, char *buffer, bool dofsync);
extern int smgrblindmarkdirty(int16 which, RelFileNode rnode,
- BlockNumber blkno);
+ BlockNumber blkno);
extern int smgrmarkdirty(int16 which, Relation reln, BlockNumber blkno);
extern int smgrnblocks(int16 which, Relation reln);
extern int smgrtruncate(int16 which, Relation reln, int nblocks);
@@ -51,7 +51,7 @@ extern int smgrsync(void);
extern void smgr_redo(XLogRecPtr lsn, XLogRecord *record);
extern void smgr_undo(XLogRecPtr lsn, XLogRecord *record);
-extern void smgr_desc(char *buf, uint8 xl_info, char* rec);
+extern void smgr_desc(char *buf, uint8 xl_info, char *rec);
/* internals: move me elsewhere -- ay 7/94 */
@@ -67,8 +67,8 @@ extern int mdread(Relation reln, BlockNumber blocknum, char *buffer);
extern int mdwrite(Relation reln, BlockNumber blocknum, char *buffer);
extern int mdflush(Relation reln, BlockNumber blocknum, char *buffer);
extern int mdmarkdirty(Relation reln, BlockNumber blkno);
-extern int mdblindwrt(RelFileNode rnode, BlockNumber blkno,
- char *buffer, bool dofsync);
+extern int mdblindwrt(RelFileNode rnode, BlockNumber blkno,
+ char *buffer, bool dofsync);
extern int mdblindmarkdirty(RelFileNode rnode, BlockNumber blkno);
extern int mdnblocks(Relation reln);
extern int mdtruncate(Relation reln, int nblocks);
diff --git a/src/include/storage/spin.h b/src/include/storage/spin.h
index 7faa19b64a5..1d488e54767 100644
--- a/src/include/storage/spin.h
+++ b/src/include/storage/spin.h
@@ -7,7 +7,7 @@
* Portions Copyright (c) 1996-2001, PostgreSQL Global Development Group
* Portions Copyright (c) 1994, Regents of the University of California
*
- * $Id: spin.h,v 1.14 2001/01/24 19:43:28 momjian Exp $
+ * $Id: spin.h,v 1.15 2001/03/22 04:01:09 momjian Exp $
*
*-------------------------------------------------------------------------
*/
@@ -29,6 +29,7 @@ typedef int SPINLOCK;
#ifdef LOCK_DEBUG
extern bool Trace_spinlocks;
+
#endif