diff options
Diffstat (limited to 'src/include')
40 files changed, 106 insertions, 100 deletions
diff --git a/src/include/access/gin_private.h b/src/include/access/gin_private.h index d1df3033a6d..c013d60371a 100644 --- a/src/include/access/gin_private.h +++ b/src/include/access/gin_private.h @@ -104,7 +104,7 @@ extern OffsetNumber gintuple_get_attrnum(GinState *ginstate, IndexTuple tuple); extern Datum gintuple_get_key(GinState *ginstate, IndexTuple tuple, GinNullCategory *category); extern void GinCheckForSerializableConflictIn(Relation relation, - HeapTuple tuple, Buffer buffer); + HeapTuple tuple, Buffer buffer); /* gininsert.c */ extern IndexBuildResult *ginbuild(Relation heap, Relation index, diff --git a/src/include/access/heapam_xlog.h b/src/include/access/heapam_xlog.h index cf88ff7cb44..695eaa1e49c 100644 --- a/src/include/access/heapam_xlog.h +++ b/src/include/access/heapam_xlog.h @@ -126,7 +126,7 @@ typedef struct xl_heap_truncate Oid dbId; uint32 nrelids; uint8 flags; - Oid relids[FLEXIBLE_ARRAY_MEMBER]; + Oid relids[FLEXIBLE_ARRAY_MEMBER]; } xl_heap_truncate; #define SizeOfHeapTruncate (offsetof(xl_heap_truncate, relids)) diff --git a/src/include/access/nbtree.h b/src/include/access/nbtree.h index 892aeca3003..15a7b4c212e 100644 --- a/src/include/access/nbtree.h +++ b/src/include/access/nbtree.h @@ -103,10 +103,10 @@ typedef struct BTMetaPageData BlockNumber btm_fastroot; /* current "fast" root location */ uint32 btm_fastlevel; /* tree level of the "fast" root page */ /* following fields are available since page version 3 */ - TransactionId btm_oldest_btpo_xact; /* oldest btpo_xact among of - * deleted pages */ - float8 btm_last_cleanup_num_heap_tuples; /* number of heap tuples - * during last cleanup */ + TransactionId btm_oldest_btpo_xact; /* oldest btpo_xact among of deleted + * pages */ + float8 btm_last_cleanup_num_heap_tuples; /* number of heap tuples + * during last cleanup */ } BTMetaPageData; #define BTPageGetMeta(p) \ @@ -115,7 +115,7 @@ typedef struct BTMetaPageData #define BTREE_METAPAGE 0 /* first page is meta */ #define BTREE_MAGIC 0x053162 /* magic number of btree pages */ #define BTREE_VERSION 3 /* current version number */ -#define BTREE_MIN_VERSION 2 /* minimal supported version number */ +#define BTREE_MIN_VERSION 2 /* minimal supported version number */ /* * Maximum size of a btree index entry, including its tuple header. @@ -537,7 +537,7 @@ extern void _bt_finish_split(Relation rel, Buffer bbuf, BTStack stack); */ extern void _bt_initmetapage(Page page, BlockNumber rootbknum, uint32 level); extern void _bt_update_meta_cleanup_info(Relation rel, - TransactionId oldestBtpoXact, float8 numHeapTuples); + TransactionId oldestBtpoXact, float8 numHeapTuples); extern void _bt_upgrademetapage(Page page); extern Buffer _bt_getroot(Relation rel, int access); extern Buffer _bt_gettrueroot(Relation rel); diff --git a/src/include/access/reloptions.h b/src/include/access/reloptions.h index ef09611e0d6..4022c14a830 100644 --- a/src/include/access/reloptions.h +++ b/src/include/access/reloptions.h @@ -51,7 +51,7 @@ typedef enum relopt_kind RELOPT_KIND_PARTITIONED = (1 << 11), /* if you add a new kind, make sure you update "last_default" too */ RELOPT_KIND_LAST_DEFAULT = RELOPT_KIND_PARTITIONED, - RELOPT_KIND_INDEX = RELOPT_KIND_BTREE|RELOPT_KIND_HASH|RELOPT_KIND_GIN|RELOPT_KIND_SPGIST, + RELOPT_KIND_INDEX = RELOPT_KIND_BTREE | RELOPT_KIND_HASH | RELOPT_KIND_GIN | RELOPT_KIND_SPGIST, /* some compilers treat enums as signed ints, so we can't use 1 << 31 */ RELOPT_KIND_MAX = (1 << 30) } relopt_kind; diff --git a/src/include/access/relscan.h b/src/include/access/relscan.h index 18c7dedd5d3..e5289b8aa7d 100644 --- a/src/include/access/relscan.h +++ b/src/include/access/relscan.h @@ -41,7 +41,7 @@ typedef struct ParallelHeapScanDescData * workers so far. */ bool phs_snapshot_any; /* SnapshotAny, not phs_snapshot_data? */ char phs_snapshot_data[FLEXIBLE_ARRAY_MEMBER]; -} ParallelHeapScanDescData; +} ParallelHeapScanDescData; typedef struct HeapScanDescData { diff --git a/src/include/access/spgist_private.h b/src/include/access/spgist_private.h index c5f1ee9ed9b..99365c8a45d 100644 --- a/src/include/access/spgist_private.h +++ b/src/include/access/spgist_private.h @@ -120,7 +120,7 @@ typedef struct SpGistState spgConfigOut config; /* filled in by opclass config method */ SpGistTypeDesc attType; /* type of values to be indexed/restored */ - SpGistTypeDesc attLeafType; /* type of leaf-tuple values */ + SpGistTypeDesc attLeafType; /* type of leaf-tuple values */ SpGistTypeDesc attPrefixType; /* type of inner-tuple prefix values */ SpGistTypeDesc attLabelType; /* type of node label values */ @@ -181,7 +181,7 @@ typedef struct SpGistCache spgConfigOut config; /* filled in by opclass config method */ SpGistTypeDesc attType; /* type of values to be indexed/restored */ - SpGistTypeDesc attLeafType; /* type of leaf-tuple values */ + SpGistTypeDesc attLeafType; /* type of leaf-tuple values */ SpGistTypeDesc attPrefixType; /* type of inner-tuple prefix values */ SpGistTypeDesc attLabelType; /* type of node label values */ diff --git a/src/include/access/twophase.h b/src/include/access/twophase.h index f05cde202f7..0e932daa484 100644 --- a/src/include/access/twophase.h +++ b/src/include/access/twophase.h @@ -48,7 +48,7 @@ extern bool StandbyTransactionIdIsPrepared(TransactionId xid); extern TransactionId PrescanPreparedTransactions(TransactionId **xids_p, int *nxids_p); extern void ParsePrepareRecord(uint8 info, char *xlrec, - xl_xact_parsed_prepare *parsed); + xl_xact_parsed_prepare *parsed); extern void StandbyRecoverPreparedTransactions(void); extern void RecoverPreparedTransactions(void); diff --git a/src/include/access/xact.h b/src/include/access/xact.h index 3661b8d0904..083e879d5c3 100644 --- a/src/include/access/xact.h +++ b/src/include/access/xact.h @@ -312,7 +312,7 @@ typedef struct xl_xact_parsed_commit SharedInvalidationMessage *msgs; TransactionId twophase_xid; /* only for 2PC */ - char twophase_gid[GIDSIZE]; /* only for 2PC */ + char twophase_gid[GIDSIZE]; /* only for 2PC */ int nabortrels; /* only for 2PC */ RelFileNode *abortnodes; /* only for 2PC */ @@ -337,7 +337,7 @@ typedef struct xl_xact_parsed_abort RelFileNode *xnodes; TransactionId twophase_xid; /* only for 2PC */ - char twophase_gid[GIDSIZE]; /* only for 2PC */ + char twophase_gid[GIDSIZE]; /* only for 2PC */ XLogRecPtr origin_lsn; TimestampTz origin_timestamp; diff --git a/src/include/catalog/pg_class.h b/src/include/catalog/pg_class.h index d1541bdfcce..dc6c415c586 100644 --- a/src/include/catalog/pg_class.h +++ b/src/include/catalog/pg_class.h @@ -67,7 +67,8 @@ CATALOG(pg_class,1259,RelationRelationId) BKI_BOOTSTRAP BKI_ROWTYPE_OID(83,Relat bool relispopulated; /* matview currently holds query results */ char relreplident; /* see REPLICA_IDENTITY_xxx constants */ bool relispartition; /* is relation a partition? */ - Oid relrewrite; /* heap for rewrite during DDL, link to original rel */ + Oid relrewrite; /* heap for rewrite during DDL, link to + * original rel */ TransactionId relfrozenxid; /* all Xids < this are frozen in this rel */ TransactionId relminmxid; /* all multixacts in this rel are >= this. * this is really a MultiXactId */ diff --git a/src/include/commands/tablecmds.h b/src/include/commands/tablecmds.h index d46e09cad4f..138de84e832 100644 --- a/src/include/commands/tablecmds.h +++ b/src/include/commands/tablecmds.h @@ -54,7 +54,7 @@ extern void CheckTableNotInUse(Relation rel, const char *stmt); extern void ExecuteTruncate(TruncateStmt *stmt); extern void ExecuteTruncateGuts(List *explicit_rels, List *relids, List *relids_logged, - DropBehavior behavior, bool restart_seqs); + DropBehavior behavior, bool restart_seqs); extern void SetRelationHasSubclass(Oid relationId, bool relhassubclass); diff --git a/src/include/common/int.h b/src/include/common/int.h index 82e38d4b7bd..ff410f0eae8 100644 --- a/src/include/common/int.h +++ b/src/include/common/int.h @@ -35,7 +35,7 @@ pg_add_s16_overflow(int16 a, int16 b, int16 *result) if (res > PG_INT16_MAX || res < PG_INT16_MIN) { - *result = 0x5EED; /* to avoid spurious warnings */ + *result = 0x5EED; /* to avoid spurious warnings */ return true; } *result = (int16) res; @@ -58,7 +58,7 @@ pg_sub_s16_overflow(int16 a, int16 b, int16 *result) if (res > PG_INT16_MAX || res < PG_INT16_MIN) { - *result = 0x5EED; /* to avoid spurious warnings */ + *result = 0x5EED; /* to avoid spurious warnings */ return true; } *result = (int16) res; @@ -81,7 +81,7 @@ pg_mul_s16_overflow(int16 a, int16 b, int16 *result) if (res > PG_INT16_MAX || res < PG_INT16_MIN) { - *result = 0x5EED; /* to avoid spurious warnings */ + *result = 0x5EED; /* to avoid spurious warnings */ return true; } *result = (int16) res; @@ -104,7 +104,7 @@ pg_add_s32_overflow(int32 a, int32 b, int32 *result) if (res > PG_INT32_MAX || res < PG_INT32_MIN) { - *result = 0x5EED; /* to avoid spurious warnings */ + *result = 0x5EED; /* to avoid spurious warnings */ return true; } *result = (int32) res; @@ -127,7 +127,7 @@ pg_sub_s32_overflow(int32 a, int32 b, int32 *result) if (res > PG_INT32_MAX || res < PG_INT32_MIN) { - *result = 0x5EED; /* to avoid spurious warnings */ + *result = 0x5EED; /* to avoid spurious warnings */ return true; } *result = (int32) res; @@ -150,7 +150,7 @@ pg_mul_s32_overflow(int32 a, int32 b, int32 *result) if (res > PG_INT32_MAX || res < PG_INT32_MIN) { - *result = 0x5EED; /* to avoid spurious warnings */ + *result = 0x5EED; /* to avoid spurious warnings */ return true; } *result = (int32) res; @@ -173,7 +173,7 @@ pg_add_s64_overflow(int64 a, int64 b, int64 *result) if (res > PG_INT64_MAX || res < PG_INT64_MIN) { - *result = 0x5EED; /* to avoid spurious warnings */ + *result = 0x5EED; /* to avoid spurious warnings */ return true; } *result = (int64) res; @@ -182,7 +182,7 @@ pg_add_s64_overflow(int64 a, int64 b, int64 *result) if ((a > 0 && b > 0 && a > PG_INT64_MAX - b) || (a < 0 && b < 0 && a < PG_INT64_MIN - b)) { - *result = 0x5EED; /* to avoid spurious warnings */ + *result = 0x5EED; /* to avoid spurious warnings */ return true; } *result = a + b; @@ -205,7 +205,7 @@ pg_sub_s64_overflow(int64 a, int64 b, int64 *result) if (res > PG_INT64_MAX || res < PG_INT64_MIN) { - *result = 0x5EED; /* to avoid spurious warnings */ + *result = 0x5EED; /* to avoid spurious warnings */ return true; } *result = (int64) res; @@ -214,7 +214,7 @@ pg_sub_s64_overflow(int64 a, int64 b, int64 *result) if ((a < 0 && b > 0 && a < PG_INT64_MIN + b) || (a > 0 && b < 0 && a > PG_INT64_MAX + b)) { - *result = 0x5EED; /* to avoid spurious warnings */ + *result = 0x5EED; /* to avoid spurious warnings */ return true; } *result = a - b; @@ -237,7 +237,7 @@ pg_mul_s64_overflow(int64 a, int64 b, int64 *result) if (res > PG_INT64_MAX || res < PG_INT64_MIN) { - *result = 0x5EED; /* to avoid spurious warnings */ + *result = 0x5EED; /* to avoid spurious warnings */ return true; } *result = (int64) res; @@ -262,7 +262,7 @@ pg_mul_s64_overflow(int64 a, int64 b, int64 *result) (a < 0 && b > 0 && a < PG_INT64_MIN / b) || (a < 0 && b < 0 && a < PG_INT64_MAX / b))) { - *result = 0x5EED; /* to avoid spurious warnings */ + *result = 0x5EED; /* to avoid spurious warnings */ return true; } *result = a * b; diff --git a/src/include/common/scram-common.h b/src/include/common/scram-common.h index 17373cce3ae..dcb5d69078f 100644 --- a/src/include/common/scram-common.h +++ b/src/include/common/scram-common.h @@ -17,7 +17,7 @@ /* Name of SCRAM mechanisms per IANA */ #define SCRAM_SHA_256_NAME "SCRAM-SHA-256" -#define SCRAM_SHA_256_PLUS_NAME "SCRAM-SHA-256-PLUS" /* with channel binding */ +#define SCRAM_SHA_256_PLUS_NAME "SCRAM-SHA-256-PLUS" /* with channel binding */ /* Channel binding types */ #define SCRAM_CHANNEL_BINDING_TLS_UNIQUE "tls-unique" diff --git a/src/include/common/string.h b/src/include/common/string.h index 63c3e81a644..78a450192e4 100644 --- a/src/include/common/string.h +++ b/src/include/common/string.h @@ -12,6 +12,6 @@ extern bool pg_str_endswith(const char *str, const char *end); extern int strtoint(const char *pg_restrict str, char **pg_restrict endptr, - int base); + int base); #endif /* COMMON_STRING_H */ diff --git a/src/include/executor/execExpr.h b/src/include/executor/execExpr.h index f4617a28fa2..f7b1f776169 100644 --- a/src/include/executor/execExpr.h +++ b/src/include/executor/execExpr.h @@ -692,9 +692,9 @@ extern void CheckExprStillValid(ExprState *state, ExprContext *econtext); * expression evaluation, reducing code duplication. */ extern void ExecEvalFuncExprFusage(ExprState *state, ExprEvalStep *op, - ExprContext *econtext); + ExprContext *econtext); extern void ExecEvalFuncExprStrictFusage(ExprState *state, ExprEvalStep *op, - ExprContext *econtext); + ExprContext *econtext); extern void ExecEvalParamExec(ExprState *state, ExprEvalStep *op, ExprContext *econtext); extern void ExecEvalParamExecParams(Bitmapset *params, EState *estate); diff --git a/src/include/executor/execPartition.h b/src/include/executor/execPartition.h index e81bdc4a0a6..8f847050e49 100644 --- a/src/include/executor/execPartition.h +++ b/src/include/executor/execPartition.h @@ -186,9 +186,9 @@ extern int ExecFindPartition(ResultRelInfo *resultRelInfo, TupleTableSlot *slot, EState *estate); extern ResultRelInfo *ExecInitPartitionInfo(ModifyTableState *mtstate, - ResultRelInfo *resultRelInfo, - PartitionTupleRouting *proute, - EState *estate, int partidx); + ResultRelInfo *resultRelInfo, + PartitionTupleRouting *proute, + EState *estate, int partidx); extern void ExecInitRoutingInfo(ModifyTableState *mtstate, EState *estate, PartitionTupleRouting *proute, @@ -204,7 +204,7 @@ extern HeapTuple ConvertPartitionTupleSlot(TupleConversionMap *map, extern void ExecCleanupTupleRouting(ModifyTableState *mtstate, PartitionTupleRouting *proute); extern PartitionPruneState *ExecSetupPartitionPruneState(PlanState *planstate, - List *partitionpruneinfo); + List *partitionpruneinfo); extern Bitmapset *ExecFindMatchingSubPlans(PartitionPruneState *prunestate); extern Bitmapset *ExecFindInitialMatchingSubPlans(PartitionPruneState *prunestate, int nsubnodes); diff --git a/src/include/executor/executor.h b/src/include/executor/executor.h index 6214d193809..a7ea3c7d109 100644 --- a/src/include/executor/executor.h +++ b/src/include/executor/executor.h @@ -433,7 +433,7 @@ extern void ExecScanReScan(ScanState *node); extern void ExecInitResultTupleSlotTL(EState *estate, PlanState *planstate); extern void ExecInitScanTupleSlot(EState *estate, ScanState *scanstate, TupleDesc tupleDesc); extern TupleTableSlot *ExecInitExtraTupleSlot(EState *estate, - TupleDesc tupleDesc); + TupleDesc tupleDesc); extern TupleTableSlot *ExecInitNullTupleSlot(EState *estate, TupleDesc tupType); extern TupleDesc ExecTypeFromTL(List *targetList, bool hasoid); diff --git a/src/include/executor/instrument.h b/src/include/executor/instrument.h index 6e3c71759b8..6d0efa7222f 100644 --- a/src/include/executor/instrument.h +++ b/src/include/executor/instrument.h @@ -59,8 +59,8 @@ typedef struct Instrumentation double ntuples; /* Total tuples produced */ double ntuples2; /* Secondary node-specific tuple counter */ double nloops; /* # of run cycles for this node */ - double nfiltered1; /* # tuples removed by scanqual or joinqual */ - double nfiltered2; /* # tuples removed by "other" quals */ + double nfiltered1; /* # tuples removed by scanqual or joinqual */ + double nfiltered2; /* # tuples removed by "other" quals */ BufferUsage bufusage; /* Total buffer usage */ } Instrumentation; diff --git a/src/include/executor/spi_priv.h b/src/include/executor/spi_priv.h index 376fae0bbc4..401fd998f70 100644 --- a/src/include/executor/spi_priv.h +++ b/src/include/executor/spi_priv.h @@ -38,8 +38,10 @@ typedef struct QueryEnvironment *queryEnv; /* query environment setup for SPI level */ /* transaction management support */ - bool atomic; /* atomic execution context, does not allow transactions */ - bool internal_xact; /* SPI-managed transaction boundary, skip cleanup */ + bool atomic; /* atomic execution context, does not allow + * transactions */ + bool internal_xact; /* SPI-managed transaction boundary, skip + * cleanup */ } _SPI_connection; /* diff --git a/src/include/executor/tuptable.h b/src/include/executor/tuptable.h index b71ec8e0698..0b874d97638 100644 --- a/src/include/executor/tuptable.h +++ b/src/include/executor/tuptable.h @@ -134,7 +134,7 @@ typedef struct TupleTableSlot HeapTupleData tts_minhdr; /* workspace for minimal-tuple-only case */ #define FIELDNO_TUPLETABLESLOT_OFF 14 uint32 tts_off; /* saved state for slot_deform_tuple */ - bool tts_fixedTupleDescriptor; /* descriptor can't be changed */ + bool tts_fixedTupleDescriptor; /* descriptor can't be changed */ } TupleTableSlot; #define TTS_HAS_PHYSICAL_TUPLE(slot) \ diff --git a/src/include/fe_utils/conditional.h b/src/include/fe_utils/conditional.h index 15162071976..9b91de5a3da 100644 --- a/src/include/fe_utils/conditional.h +++ b/src/include/fe_utils/conditional.h @@ -75,7 +75,7 @@ extern ConditionalStack conditional_stack_create(void); extern void conditional_stack_destroy(ConditionalStack cstack); -extern int conditional_stack_depth(ConditionalStack cstack); +extern int conditional_stack_depth(ConditionalStack cstack); extern void conditional_stack_push(ConditionalStack cstack, ifState new_state); diff --git a/src/include/libpq/libpq.h b/src/include/libpq/libpq.h index a74ad521b5a..7bf06c65e96 100644 --- a/src/include/libpq/libpq.h +++ b/src/include/libpq/libpq.h @@ -106,8 +106,8 @@ extern bool SSLPreferServerCiphers; * prototypes for functions in be-secure-common.c */ extern int run_ssl_passphrase_command(const char *prompt, bool is_server_start, - char *buf, int size); + char *buf, int size); extern bool check_ssl_key_file_permissions(const char *ssl_key_file, - bool isServerStart); + bool isServerStart); #endif /* LIBPQ_H */ diff --git a/src/include/nodes/execnodes.h b/src/include/nodes/execnodes.h index fe93e78bee8..da7f52cab09 100644 --- a/src/include/nodes/execnodes.h +++ b/src/include/nodes/execnodes.h @@ -502,8 +502,8 @@ typedef struct EState int es_num_root_result_relations; /* length of the array */ /* - * The following list contains ResultRelInfos created by the tuple - * routing code for partitions that don't already have one. + * The following list contains ResultRelInfos created by the tuple routing + * code for partitions that don't already have one. */ List *es_tuple_routing_result_relations; @@ -836,7 +836,8 @@ typedef struct SubPlanState MemoryContext hashtempcxt; /* temp memory context for hash tables */ ExprContext *innerecontext; /* econtext for computing inner tuples */ AttrNumber *keyColIdx; /* control data for hash tables */ - Oid *tab_eq_funcoids;/* equality func oids for table datatype(s) */ + Oid *tab_eq_funcoids; /* equality func oids for table + * datatype(s) */ FmgrInfo *tab_hash_funcs; /* hash functions for table datatype(s) */ FmgrInfo *tab_eq_funcs; /* equality functions for table datatype(s) */ FmgrInfo *lhs_hash_funcs; /* hash functions for lefthand datatype(s) */ @@ -1087,8 +1088,8 @@ struct AppendState PlanState **appendplans; /* array of PlanStates for my inputs */ int as_nplans; int as_whichplan; - int as_first_partial_plan; /* Index of 'appendplans' containing - * the first partial plan */ + int as_first_partial_plan; /* Index of 'appendplans' containing + * the first partial plan */ ParallelAppendState *as_pstate; /* parallel coordination info */ Size pstate_len; /* size of parallel coordination info */ struct PartitionPruneState *as_prune_state; @@ -1958,8 +1959,8 @@ typedef struct WindowAggState WindowStatePerFunc perfunc; /* per-window-function information */ WindowStatePerAgg peragg; /* per-plain-aggregate information */ - ExprState *partEqfunction; /* equality funcs for partition columns */ - ExprState *ordEqfunction; /* equality funcs for ordering columns */ + ExprState *partEqfunction; /* equality funcs for partition columns */ + ExprState *ordEqfunction; /* equality funcs for ordering columns */ Tuplestorestate *buffer; /* stores rows of current partition */ int current_ptr; /* read pointer # for current row */ int framehead_ptr; /* read pointer # for frame head, if used */ @@ -2037,7 +2038,7 @@ typedef struct WindowAggState typedef struct UniqueState { PlanState ps; /* its first field is NodeTag */ - ExprState *eqfunction; /* tuple equality qual */ + ExprState *eqfunction; /* tuple equality qual */ } UniqueState; /* ---------------- diff --git a/src/include/nodes/parsenodes.h b/src/include/nodes/parsenodes.h index cbbe0650783..6390f7e8c12 100644 --- a/src/include/nodes/parsenodes.h +++ b/src/include/nodes/parsenodes.h @@ -655,8 +655,8 @@ typedef struct ColumnDef Node *raw_default; /* default value (untransformed parse tree) */ Node *cooked_default; /* default value (transformed expr tree) */ char identity; /* attidentity setting */ - RangeVar *identitySequence; /* to store identity sequence name for ALTER - * TABLE ... ADD COLUMN */ + RangeVar *identitySequence; /* to store identity sequence name for + * ALTER TABLE ... ADD COLUMN */ CollateClause *collClause; /* untransformed COLLATE spec, if any */ Oid collOid; /* collation OID (InvalidOid if not set) */ List *constraints; /* other constraints on column */ @@ -2974,7 +2974,7 @@ typedef struct TransactionStmt NodeTag type; TransactionStmtKind kind; /* see above */ List *options; /* for BEGIN/START commands */ - char *savepoint_name; /* for savepoint commands */ + char *savepoint_name; /* for savepoint commands */ char *gid; /* for two-phase-commit related commands */ } TransactionStmt; diff --git a/src/include/nodes/relation.h b/src/include/nodes/relation.h index 8b153a9d4e8..3b28d1994f1 100644 --- a/src/include/nodes/relation.h +++ b/src/include/nodes/relation.h @@ -309,9 +309,9 @@ typedef struct PlannerInfo Index qual_security_level; /* minimum security_level for quals */ /* Note: qual_security_level is zero if there are no securityQuals */ - InheritanceKind inhTargetKind; /* indicates if the target relation is an - * inheritance child or partition or a - * partitioned table */ + InheritanceKind inhTargetKind; /* indicates if the target relation is an + * inheritance child or partition or a + * partitioned table */ bool hasJoinRTEs; /* true if any RTEs are RTE_JOIN kind */ bool hasLateralRTEs; /* true if any RTEs are marked LATERAL */ bool hasDeletedRTEs; /* true if any RTE was deleted from jointree */ diff --git a/src/include/optimizer/cost.h b/src/include/optimizer/cost.h index 55e6a8488fe..77ca7ff8371 100644 --- a/src/include/optimizer/cost.h +++ b/src/include/optimizer/cost.h @@ -54,7 +54,7 @@ extern PGDLLIMPORT double parallel_tuple_cost; extern PGDLLIMPORT double parallel_setup_cost; extern PGDLLIMPORT int effective_cache_size; extern PGDLLIMPORT Cost disable_cost; -extern PGDLLIMPORT int max_parallel_workers_per_gather; +extern PGDLLIMPORT int max_parallel_workers_per_gather; extern PGDLLIMPORT bool enable_seqscan; extern PGDLLIMPORT bool enable_indexscan; extern PGDLLIMPORT bool enable_indexonlyscan; @@ -72,7 +72,7 @@ extern PGDLLIMPORT bool enable_partitionwise_aggregate; extern PGDLLIMPORT bool enable_parallel_append; extern PGDLLIMPORT bool enable_parallel_hash; extern PGDLLIMPORT bool enable_partition_pruning; -extern PGDLLIMPORT int constraint_exclusion; +extern PGDLLIMPORT int constraint_exclusion; extern double clamp_row_est(double nrows); extern double index_pages_fetched(double tuples_fetched, BlockNumber pages, diff --git a/src/include/optimizer/paths.h b/src/include/optimizer/paths.h index f181586a532..cafde307adb 100644 --- a/src/include/optimizer/paths.h +++ b/src/include/optimizer/paths.h @@ -21,9 +21,9 @@ * allpaths.c */ extern PGDLLIMPORT bool enable_geqo; -extern PGDLLIMPORT int geqo_threshold; -extern PGDLLIMPORT int min_parallel_table_scan_size; -extern PGDLLIMPORT int min_parallel_index_scan_size; +extern PGDLLIMPORT int geqo_threshold; +extern PGDLLIMPORT int min_parallel_table_scan_size; +extern PGDLLIMPORT int min_parallel_index_scan_size; /* Hook for plugins to get control in set_rel_pathlist() */ typedef void (*set_rel_pathlist_hook_type) (PlannerInfo *root, @@ -60,7 +60,7 @@ extern int compute_parallel_worker(RelOptInfo *rel, double heap_pages, extern void create_partial_bitmap_paths(PlannerInfo *root, RelOptInfo *rel, Path *bitmapqual); extern void generate_partitionwise_join_paths(PlannerInfo *root, - RelOptInfo *rel); + RelOptInfo *rel); #ifdef OPTIMIZER_DEBUG extern void debug_print_rel(PlannerInfo *root, RelOptInfo *rel); diff --git a/src/include/parser/parse_func.h b/src/include/parser/parse_func.h index 2e3810fc32f..11f9046e385 100644 --- a/src/include/parser/parse_func.h +++ b/src/include/parser/parse_func.h @@ -32,8 +32,8 @@ typedef enum extern Node *ParseFuncOrColumn(ParseState *pstate, List *funcname, List *fargs, - Node *last_srf, FuncCall *fn, bool proc_call, - int location); + Node *last_srf, FuncCall *fn, bool proc_call, + int location); extern FuncDetailCode func_get_detail(List *funcname, List *fargs, List *fargnames, diff --git a/src/include/replication/logical.h b/src/include/replication/logical.h index 619c5f4d73e..c25ac1fa85a 100644 --- a/src/include/replication/logical.h +++ b/src/include/replication/logical.h @@ -46,11 +46,11 @@ typedef struct LogicalDecodingContext struct SnapBuild *snapshot_builder; /* - * Marks the logical decoding context as fast forward decoding one. - * Such a context does not have plugin loaded so most of the the following + * Marks the logical decoding context as fast forward decoding one. Such a + * context does not have plugin loaded so most of the the following * properties are unused. */ - bool fast_forward; + bool fast_forward; OutputPluginCallbacks callbacks; OutputPluginOptions options; diff --git a/src/include/replication/logicalproto.h b/src/include/replication/logicalproto.h index 92e88d31279..8192f79ce31 100644 --- a/src/include/replication/logicalproto.h +++ b/src/include/replication/logicalproto.h @@ -98,9 +98,9 @@ extern void logicalrep_write_delete(StringInfo out, Relation rel, extern LogicalRepRelId logicalrep_read_delete(StringInfo in, LogicalRepTupleData *oldtup); extern void logicalrep_write_truncate(StringInfo out, int nrelids, Oid relids[], - bool cascade, bool restart_seqs); + bool cascade, bool restart_seqs); extern List *logicalrep_read_truncate(StringInfo in, - bool *cascade, bool *restart_seqs); + bool *cascade, bool *restart_seqs); extern void logicalrep_write_rel(StringInfo out, Relation rel); extern LogicalRepRelation *logicalrep_read_rel(StringInfo in); extern void logicalrep_write_typ(StringInfo out, Oid typoid); diff --git a/src/include/replication/reorderbuffer.h b/src/include/replication/reorderbuffer.h index 3867ce89505..1c7982958e0 100644 --- a/src/include/replication/reorderbuffer.h +++ b/src/include/replication/reorderbuffer.h @@ -101,8 +101,8 @@ typedef struct ReorderBufferChange } tp; /* - * Truncate data for REORDER_BUFFER_CHANGE_TRUNCATE representing - * one set of relations to be truncated. + * Truncate data for REORDER_BUFFER_CHANGE_TRUNCATE representing one + * set of relations to be truncated. */ struct { @@ -110,7 +110,7 @@ typedef struct ReorderBufferChange bool cascade; bool restart_seqs; Oid *relids; - } truncate; + } truncate; /* Message with arbitrary data. */ struct diff --git a/src/include/replication/walreceiver.h b/src/include/replication/walreceiver.h index 76268ceb23f..5913b580c2b 100644 --- a/src/include/replication/walreceiver.h +++ b/src/include/replication/walreceiver.h @@ -110,8 +110,8 @@ typedef struct char conninfo[MAXCONNINFO]; /* - * Host name (this can be a host name, an IP address, or a directory - * path) and port number of the active replication connection. + * Host name (this can be a host name, an IP address, or a directory path) + * and port number of the active replication connection. */ char sender_host[NI_MAXHOST]; int sender_port; @@ -206,8 +206,8 @@ typedef WalReceiverConn *(*walrcv_connect_fn) (const char *conninfo, bool logica typedef void (*walrcv_check_conninfo_fn) (const char *conninfo); typedef char *(*walrcv_get_conninfo_fn) (WalReceiverConn *conn); typedef void (*walrcv_get_senderinfo_fn) (WalReceiverConn *conn, - char **sender_host, - int *sender_port); + char **sender_host, + int *sender_port); typedef char *(*walrcv_identify_system_fn) (WalReceiverConn *conn, TimeLineID *primary_tli, int *server_version); diff --git a/src/include/storage/reinit.h b/src/include/storage/reinit.h index 22639dab4c1..a62703c6474 100644 --- a/src/include/storage/reinit.h +++ b/src/include/storage/reinit.h @@ -20,7 +20,7 @@ extern void ResetUnloggedRelations(int op); extern bool parse_filename_for_nontemp_relation(const char *name, - int *oidchars, ForkNumber *fork); + int *oidchars, ForkNumber *fork); #define UNLOGGED_RELATION_CLEANUP 0x0001 #define UNLOGGED_RELATION_INIT 0x0002 diff --git a/src/include/tcop/utility.h b/src/include/tcop/utility.h index 880d19311a6..da6767917cc 100644 --- a/src/include/tcop/utility.h +++ b/src/include/tcop/utility.h @@ -20,7 +20,8 @@ typedef enum { PROCESS_UTILITY_TOPLEVEL, /* toplevel interactive command */ PROCESS_UTILITY_QUERY, /* a complete query, but not toplevel */ - PROCESS_UTILITY_QUERY_NONATOMIC, /* a complete query, nonatomic execution context */ + PROCESS_UTILITY_QUERY_NONATOMIC, /* a complete query, nonatomic + * execution context */ PROCESS_UTILITY_SUBCOMMAND /* a portion of a query */ } ProcessUtilityContext; diff --git a/src/include/tsearch/ts_utils.h b/src/include/tsearch/ts_utils.h index 73e969fe9ce..d59e38c36b0 100644 --- a/src/include/tsearch/ts_utils.h +++ b/src/include/tsearch/ts_utils.h @@ -62,9 +62,9 @@ typedef void (*PushFunction) (Datum opaque, TSQueryParserState state, #define P_TSQ_WEB (1 << 1) extern TSQuery parse_tsquery(char *buf, - PushFunction pushval, - Datum opaque, - int flags); + PushFunction pushval, + Datum opaque, + int flags); /* Functions for use by PushFunction implementations */ extern void pushValue(TSQueryParserState state, diff --git a/src/include/utils/jsonapi.h b/src/include/utils/jsonapi.h index b28201c2bc6..6b483a15a66 100644 --- a/src/include/utils/jsonapi.h +++ b/src/include/utils/jsonapi.h @@ -136,12 +136,13 @@ extern bool IsValidJsonNumber(const char *str, int len); * Flag types for iterate_json(b)_values to specify what elements from a * json(b) document we want to iterate. */ -typedef enum JsonToIndex { - jtiKey = 0x01, - jtiString = 0x02, - jtiNumeric = 0x04, - jtiBool = 0x08, - jtiAll = jtiKey | jtiString | jtiNumeric | jtiBool +typedef enum JsonToIndex +{ + jtiKey = 0x01, + jtiString = 0x02, + jtiNumeric = 0x04, + jtiBool = 0x08, + jtiAll = jtiKey | jtiString | jtiNumeric | jtiBool } JsonToIndex; /* an action that will be applied to each value in iterate_json(b)_vaues functions */ @@ -152,9 +153,9 @@ typedef text *(*JsonTransformStringValuesAction) (void *state, char *elem_value, extern uint32 parse_jsonb_index_flags(Jsonb *jb); extern void iterate_jsonb_values(Jsonb *jb, uint32 flags, void *state, - JsonIterateStringValuesAction action); + JsonIterateStringValuesAction action); extern void iterate_json_values(text *json, uint32 flags, void *action_state, - JsonIterateStringValuesAction action); + JsonIterateStringValuesAction action); extern Jsonb *transform_jsonb_string_values(Jsonb *jsonb, void *action_state, JsonTransformStringValuesAction transform_action); extern text *transform_json_string_values(text *json, void *action_state, diff --git a/src/include/utils/partcache.h b/src/include/utils/partcache.h index c1d029fdb31..873c60fafd2 100644 --- a/src/include/utils/partcache.h +++ b/src/include/utils/partcache.h @@ -44,7 +44,7 @@ typedef struct PartitionKeyData bool *parttypbyval; char *parttypalign; Oid *parttypcoll; -} PartitionKeyData; +} PartitionKeyData; extern void RelationBuildPartitionKey(Relation relation); extern void RelationBuildPartitionDesc(Relation rel); diff --git a/src/include/utils/portal.h b/src/include/utils/portal.h index b4a259dcf8f..e4929b936e5 100644 --- a/src/include/utils/portal.h +++ b/src/include/utils/portal.h @@ -116,7 +116,7 @@ typedef struct PortalData /* Bookkeeping data */ const char *name; /* portal's name */ const char *prepStmtName; /* source prepared statement (NULL if none) */ - MemoryContext portalContext;/* subsidiary memory for portal */ + MemoryContext portalContext; /* subsidiary memory for portal */ ResourceOwner resowner; /* resources owned by portal */ void (*cleanup) (Portal portal); /* cleanup hook */ diff --git a/src/include/utils/rel.h b/src/include/utils/rel.h index 1d0461d2957..c97f9d1b43e 100644 --- a/src/include/utils/rel.h +++ b/src/include/utils/rel.h @@ -116,7 +116,7 @@ typedef struct RelationData Bitmapset *rd_keyattr; /* cols that can be ref'd by foreign keys */ Bitmapset *rd_pkattr; /* cols included in primary key */ Bitmapset *rd_idattr; /* included in replica identity index */ - Bitmapset *rd_projidx; /* Oids of projection indexes */ + Bitmapset *rd_projidx; /* Oids of projection indexes */ PublicationActions *rd_pubactions; /* publication actions */ @@ -223,7 +223,7 @@ typedef struct ForeignKeyCacheInfo typedef struct GenericIndexOpts { int32 vl_len_; - bool recheck_on_update; + bool recheck_on_update; } GenericIndexOpts; /* diff --git a/src/include/utils/resowner_private.h b/src/include/utils/resowner_private.h index 44dc99eb267..a6e8eb71abb 100644 --- a/src/include/utils/resowner_private.h +++ b/src/include/utils/resowner_private.h @@ -91,8 +91,8 @@ extern void ResourceOwnerForgetDSM(ResourceOwner owner, /* support for JITContext management */ extern void ResourceOwnerEnlargeJIT(ResourceOwner owner); extern void ResourceOwnerRememberJIT(ResourceOwner owner, - Datum handle); + Datum handle); extern void ResourceOwnerForgetJIT(ResourceOwner owner, - Datum handle); + Datum handle); #endif /* RESOWNER_PRIVATE_H */ diff --git a/src/include/utils/tuplesort.h b/src/include/utils/tuplesort.h index d2e6754f043..32908b66251 100644 --- a/src/include/utils/tuplesort.h +++ b/src/include/utils/tuplesort.h @@ -54,7 +54,7 @@ typedef struct SortCoordinateData /* Private opaque state (points to shared memory) */ Sharedsort *sharedsort; -} SortCoordinateData; +} SortCoordinateData; typedef struct SortCoordinateData *SortCoordinate; |