Location via proxy:   [ UP ]  
[Report a bug]   [Manage cookies]                
Skip to content

Commit 6207f08

Browse files
Harmonize function parameter names for Postgres 17.
Make sure that function declarations use names that exactly match the corresponding names from function definitions in a few places. These inconsistencies were all introduced during Postgres 17 development. pg_bsd_indent still has a couple of similar inconsistencies, which I (pgeoghegan) have left untouched for now. This commit was written with help from clang-tidy, by mechanically applying the same rules as similar clean-up commits (the earliest such commit was commit 035ce1f).
1 parent a0fe90e commit 6207f08

File tree

27 files changed

+65
-63
lines changed

27 files changed

+65
-63
lines changed

src/backend/access/brin/brin.c

+3-3
Original file line numberDiff line numberDiff line change
@@ -229,11 +229,11 @@ static void _brin_begin_parallel(BrinBuildState *buildstate, Relation heap, Rela
229229
bool isconcurrent, int request);
230230
static void _brin_end_parallel(BrinLeader *brinleader, BrinBuildState *state);
231231
static Size _brin_parallel_estimate_shared(Relation heap, Snapshot snapshot);
232-
static double _brin_parallel_heapscan(BrinBuildState *buildstate);
233-
static double _brin_parallel_merge(BrinBuildState *buildstate);
232+
static double _brin_parallel_heapscan(BrinBuildState *state);
233+
static double _brin_parallel_merge(BrinBuildState *state);
234234
static void _brin_leader_participate_as_worker(BrinBuildState *buildstate,
235235
Relation heap, Relation index);
236-
static void _brin_parallel_scan_and_build(BrinBuildState *buildstate,
236+
static void _brin_parallel_scan_and_build(BrinBuildState *state,
237237
BrinShared *brinshared,
238238
Sharedsort *sharedsort,
239239
Relation heap, Relation index,

src/backend/access/heap/vacuumlazy.c

+1-1
Original file line numberDiff line numberDiff line change
@@ -246,7 +246,7 @@ static void lazy_vacuum(LVRelState *vacrel);
246246
static bool lazy_vacuum_all_indexes(LVRelState *vacrel);
247247
static void lazy_vacuum_heap_rel(LVRelState *vacrel);
248248
static void lazy_vacuum_heap_page(LVRelState *vacrel, BlockNumber blkno,
249-
Buffer buffer, OffsetNumber *offsets,
249+
Buffer buffer, OffsetNumber *deadoffsets,
250250
int num_offsets, Buffer vmbuffer);
251251
static bool lazy_check_wraparound_failsafe(LVRelState *vacrel);
252252
static void lazy_cleanup_all_indexes(LVRelState *vacrel);

src/backend/backup/basebackup_incremental.c

+1-1
Original file line numberDiff line numberDiff line change
@@ -141,7 +141,7 @@ static void manifest_process_wal_range(JsonManifestParseContext *context,
141141
TimeLineID tli,
142142
XLogRecPtr start_lsn,
143143
XLogRecPtr end_lsn);
144-
static void manifest_report_error(JsonManifestParseContext *ib,
144+
static void manifest_report_error(JsonManifestParseContext *context,
145145
const char *fmt,...)
146146
pg_attribute_printf(2, 3) pg_attribute_noreturn();
147147
static int compare_block_numbers(const void *a, const void *b);

src/backend/backup/basebackup_zstd.c

+1-1
Original file line numberDiff line numberDiff line change
@@ -34,7 +34,7 @@ typedef struct bbsink_zstd
3434

3535
static void bbsink_zstd_begin_backup(bbsink *sink);
3636
static void bbsink_zstd_begin_archive(bbsink *sink, const char *archive_name);
37-
static void bbsink_zstd_archive_contents(bbsink *sink, size_t avail_in);
37+
static void bbsink_zstd_archive_contents(bbsink *sink, size_t len);
3838
static void bbsink_zstd_manifest_contents(bbsink *sink, size_t len);
3939
static void bbsink_zstd_end_archive(bbsink *sink);
4040
static void bbsink_zstd_cleanup(bbsink *sink);

src/backend/commands/tablecmds.c

+1-1
Original file line numberDiff line numberDiff line change
@@ -589,7 +589,7 @@ static ObjectAddress ATExecClusterOn(Relation rel, const char *indexName,
589589
LOCKMODE lockmode);
590590
static void ATExecDropCluster(Relation rel, LOCKMODE lockmode);
591591
static void ATPrepSetAccessMethod(AlteredTableInfo *tab, Relation rel, const char *amname);
592-
static void ATExecSetAccessMethodNoStorage(Relation rel, Oid newAccessMethod);
592+
static void ATExecSetAccessMethodNoStorage(Relation rel, Oid newAccessMethodId);
593593
static bool ATPrepChangePersistence(Relation rel, bool toLogged);
594594
static void ATPrepSetTableSpace(AlteredTableInfo *tab, Relation rel,
595595
const char *tablespacename, LOCKMODE lockmode);

src/backend/optimizer/path/joinrels.c

+1-1
Original file line numberDiff line numberDiff line change
@@ -45,7 +45,7 @@ static void try_partitionwise_join(PlannerInfo *root, RelOptInfo *rel1,
4545
static SpecialJoinInfo *build_child_join_sjinfo(PlannerInfo *root,
4646
SpecialJoinInfo *parent_sjinfo,
4747
Relids left_relids, Relids right_relids);
48-
static void free_child_join_sjinfo(SpecialJoinInfo *child_sjinfo);
48+
static void free_child_join_sjinfo(SpecialJoinInfo *sjinfo);
4949
static void compute_partition_bounds(PlannerInfo *root, RelOptInfo *rel1,
5050
RelOptInfo *rel2, RelOptInfo *joinrel,
5151
SpecialJoinInfo *parent_sjinfo,

src/backend/parser/parse_expr.c

+3-3
Original file line numberDiff line numberDiff line change
@@ -88,11 +88,11 @@ static Node *transformJsonArrayQueryConstructor(ParseState *pstate,
8888
static Node *transformJsonObjectAgg(ParseState *pstate, JsonObjectAgg *agg);
8989
static Node *transformJsonArrayAgg(ParseState *pstate, JsonArrayAgg *agg);
9090
static Node *transformJsonIsPredicate(ParseState *pstate, JsonIsPredicate *pred);
91-
static Node *transformJsonParseExpr(ParseState *pstate, JsonParseExpr *expr);
92-
static Node *transformJsonScalarExpr(ParseState *pstate, JsonScalarExpr *expr);
91+
static Node *transformJsonParseExpr(ParseState *pstate, JsonParseExpr *jsexpr);
92+
static Node *transformJsonScalarExpr(ParseState *pstate, JsonScalarExpr *jsexpr);
9393
static Node *transformJsonSerializeExpr(ParseState *pstate,
9494
JsonSerializeExpr *expr);
95-
static Node *transformJsonFuncExpr(ParseState *pstate, JsonFuncExpr *p);
95+
static Node *transformJsonFuncExpr(ParseState *pstate, JsonFuncExpr *func);
9696
static void transformJsonPassingArgs(ParseState *pstate, const char *constructName,
9797
JsonFormatType format, List *args,
9898
List **passing_values, List **passing_names);

src/backend/replication/libpqwalreceiver/libpqwalreceiver.c

+1-1
Original file line numberDiff line numberDiff line change
@@ -59,7 +59,7 @@ static void libpqrcv_get_senderinfo(WalReceiverConn *conn,
5959
char **sender_host, int *sender_port);
6060
static char *libpqrcv_identify_system(WalReceiverConn *conn,
6161
TimeLineID *primary_tli);
62-
static char *libpqrcv_get_dbname_from_conninfo(const char *conninfo);
62+
static char *libpqrcv_get_dbname_from_conninfo(const char *connInfo);
6363
static int libpqrcv_server_version(WalReceiverConn *conn);
6464
static void libpqrcv_readtimelinehistoryfile(WalReceiverConn *conn,
6565
TimeLineID tli, char **filename,

src/backend/utils/adt/jsonpath_exec.c

+2-3
Original file line numberDiff line numberDiff line change
@@ -318,7 +318,7 @@ static void getJsonPathVariable(JsonPathExecContext *cxt,
318318
JsonPathItem *variable, JsonbValue *value);
319319
static int countVariablesFromJsonb(void *varsJsonb);
320320
static JsonbValue *getJsonPathVariableFromJsonb(void *varsJsonb, char *varName,
321-
int varNameLen,
321+
int varNameLength,
322322
JsonbValue *baseObject,
323323
int *baseObjectId);
324324
static int JsonbArraySize(JsonbValue *jb);
@@ -342,7 +342,6 @@ static void JsonValueListInitIterator(const JsonValueList *jvl,
342342
JsonValueListIterator *it);
343343
static JsonbValue *JsonValueListNext(const JsonValueList *jvl,
344344
JsonValueListIterator *it);
345-
static int JsonbType(JsonbValue *jb);
346345
static JsonbValue *JsonbInitBinary(JsonbValue *jbv, Jsonb *jb);
347346
static int JsonbType(JsonbValue *jb);
348347
static JsonbValue *getScalar(JsonbValue *scalar, enum jbvType type);
@@ -359,7 +358,7 @@ static JsonTablePlanState *JsonTableInitPlan(JsonTableExecContext *cxt,
359358
List *args,
360359
MemoryContext mcxt);
361360
static void JsonTableSetDocument(TableFuncScanState *state, Datum value);
362-
static void JsonTableResetRowPattern(JsonTablePlanState *plan, Datum item);
361+
static void JsonTableResetRowPattern(JsonTablePlanState *planstate, Datum item);
363362
static bool JsonTableFetchRow(TableFuncScanState *state);
364363
static Datum JsonTableGetValue(TableFuncScanState *state, int colnum,
365364
Oid typid, int32 typmod, bool *isnull);

src/bin/pg_combinebackup/copy_file.c

+2-2
Original file line numberDiff line numberDiff line change
@@ -25,10 +25,10 @@
2525
static void copy_file_blocks(const char *src, const char *dst,
2626
pg_checksum_context *checksum_ctx);
2727

28-
static void copy_file_clone(const char *src, const char *dst,
28+
static void copy_file_clone(const char *src, const char *dest,
2929
pg_checksum_context *checksum_ctx);
3030

31-
static void copy_file_by_range(const char *src, const char *dst,
31+
static void copy_file_by_range(const char *src, const char *dest,
3232
pg_checksum_context *checksum_ctx);
3333

3434
#ifdef WIN32

src/bin/pg_combinebackup/reconstruct.c

+1-1
Original file line numberDiff line numberDiff line change
@@ -62,7 +62,7 @@ static void write_reconstructed_file(char *input_filename,
6262
bool debug,
6363
bool dry_run);
6464
static void read_bytes(rfile *rf, void *buffer, unsigned length);
65-
static void write_block(int wfd, char *output_filename,
65+
static void write_block(int fd, char *output_filename,
6666
uint8 *buffer,
6767
pg_checksum_context *checksum_ctx);
6868
static void read_block(rfile *s, off_t off, uint8 *buffer);

src/bin/pg_dump/pg_dumpall.c

+1-1
Original file line numberDiff line numberDiff line change
@@ -80,7 +80,7 @@ static PGresult *executeQuery(PGconn *conn, const char *query);
8080
static void executeCommand(PGconn *conn, const char *query);
8181
static void expand_dbname_patterns(PGconn *conn, SimpleStringList *patterns,
8282
SimpleStringList *names);
83-
static void read_dumpall_filters(const char *filename, SimpleStringList *patterns);
83+
static void read_dumpall_filters(const char *filename, SimpleStringList *pattern);
8484

8585
static char pg_dump_bin[MAXPGPATH];
8686
static const char *progname;

src/bin/pg_dump/pg_restore.c

+1-1
Original file line numberDiff line numberDiff line change
@@ -53,7 +53,7 @@
5353
#include "pg_backup_utils.h"
5454

5555
static void usage(const char *progname);
56-
static void read_restore_filters(const char *filename, RestoreOptions *dopt);
56+
static void read_restore_filters(const char *filename, RestoreOptions *opts);
5757

5858
int
5959
main(int argc, char **argv)

src/include/access/heapam.h

+1-1
Original file line numberDiff line numberDiff line change
@@ -382,7 +382,7 @@ extern void heap_page_prune_execute(Buffer buffer, bool lp_truncate_only,
382382
extern void heap_get_root_tuples(Page page, OffsetNumber *root_offsets);
383383
extern void log_heap_prune_and_freeze(Relation relation, Buffer buffer,
384384
TransactionId conflict_xid,
385-
bool lp_truncate_only,
385+
bool cleanup_lock,
386386
PruneReason reason,
387387
HeapTupleFreeze *frozen, int nfrozen,
388388
OffsetNumber *redirected, int nredirected,

src/include/common/unicode_case.h

+3-3
Original file line numberDiff line numberDiff line change
@@ -18,9 +18,9 @@
1818

1919
typedef size_t (*WordBoundaryNext) (void *wbstate);
2020

21-
pg_wchar unicode_lowercase_simple(pg_wchar ucs);
22-
pg_wchar unicode_titlecase_simple(pg_wchar ucs);
23-
pg_wchar unicode_uppercase_simple(pg_wchar ucs);
21+
pg_wchar unicode_lowercase_simple(pg_wchar code);
22+
pg_wchar unicode_titlecase_simple(pg_wchar code);
23+
pg_wchar unicode_uppercase_simple(pg_wchar code);
2424
size_t unicode_strlower(char *dst, size_t dstsize, const char *src,
2525
ssize_t srclen);
2626
size_t unicode_strtitle(char *dst, size_t dstsize, const char *src,

src/include/common/unicode_category.h

+22-22
Original file line numberDiff line numberDiff line change
@@ -61,31 +61,31 @@ typedef enum pg_unicode_category
6161
PG_U_FINAL_PUNCTUATION = 29 /* Pf */
6262
} pg_unicode_category;
6363

64-
extern pg_unicode_category unicode_category(pg_wchar ucs);
64+
extern pg_unicode_category unicode_category(pg_wchar code);
6565
extern const char *unicode_category_string(pg_unicode_category category);
6666
extern const char *unicode_category_abbrev(pg_unicode_category category);
6767

68-
extern bool pg_u_prop_alphabetic(pg_wchar c);
69-
extern bool pg_u_prop_lowercase(pg_wchar c);
70-
extern bool pg_u_prop_uppercase(pg_wchar c);
71-
extern bool pg_u_prop_cased(pg_wchar c);
72-
extern bool pg_u_prop_case_ignorable(pg_wchar c);
73-
extern bool pg_u_prop_white_space(pg_wchar c);
74-
extern bool pg_u_prop_hex_digit(pg_wchar c);
75-
extern bool pg_u_prop_join_control(pg_wchar c);
68+
extern bool pg_u_prop_alphabetic(pg_wchar code);
69+
extern bool pg_u_prop_lowercase(pg_wchar code);
70+
extern bool pg_u_prop_uppercase(pg_wchar code);
71+
extern bool pg_u_prop_cased(pg_wchar code);
72+
extern bool pg_u_prop_case_ignorable(pg_wchar code);
73+
extern bool pg_u_prop_white_space(pg_wchar code);
74+
extern bool pg_u_prop_hex_digit(pg_wchar code);
75+
extern bool pg_u_prop_join_control(pg_wchar code);
7676

77-
extern bool pg_u_isdigit(pg_wchar c, bool posix);
78-
extern bool pg_u_isalpha(pg_wchar c);
79-
extern bool pg_u_isalnum(pg_wchar c, bool posix);
80-
extern bool pg_u_isword(pg_wchar c);
81-
extern bool pg_u_isupper(pg_wchar c);
82-
extern bool pg_u_islower(pg_wchar c);
83-
extern bool pg_u_isblank(pg_wchar c);
84-
extern bool pg_u_iscntrl(pg_wchar c);
85-
extern bool pg_u_isgraph(pg_wchar c);
86-
extern bool pg_u_isprint(pg_wchar c);
87-
extern bool pg_u_ispunct(pg_wchar c, bool posix);
88-
extern bool pg_u_isspace(pg_wchar c);
89-
extern bool pg_u_isxdigit(pg_wchar c, bool posix);
77+
extern bool pg_u_isdigit(pg_wchar code, bool posix);
78+
extern bool pg_u_isalpha(pg_wchar code);
79+
extern bool pg_u_isalnum(pg_wchar code, bool posix);
80+
extern bool pg_u_isword(pg_wchar code);
81+
extern bool pg_u_isupper(pg_wchar code);
82+
extern bool pg_u_islower(pg_wchar code);
83+
extern bool pg_u_isblank(pg_wchar code);
84+
extern bool pg_u_iscntrl(pg_wchar code);
85+
extern bool pg_u_isgraph(pg_wchar code);
86+
extern bool pg_u_isprint(pg_wchar code);
87+
extern bool pg_u_ispunct(pg_wchar code, bool posix);
88+
extern bool pg_u_isspace(pg_wchar code);
89+
extern bool pg_u_isxdigit(pg_wchar code, bool posix);
9090

9191
#endif /* UNICODE_CATEGORY_H */

src/include/libpq/libpq.h

+1-1
Original file line numberDiff line numberDiff line change
@@ -66,7 +66,7 @@ extern PGDLLIMPORT WaitEventSet *FeBeWaitSet;
6666

6767
extern int ListenServerPort(int family, const char *hostName,
6868
unsigned short portNumber, const char *unixSocketDir,
69-
pgsocket ListenSocket[], int *NumListenSockets, int MaxListen);
69+
pgsocket ListenSockets[], int *NumListenSockets, int MaxListen);
7070
extern int AcceptConnection(pgsocket server_fd, ClientSocket *client_sock);
7171
extern void TouchSocketFiles(void);
7272
extern void RemoveSocketFiles(void);

src/include/postmaster/postmaster.h

+4-1
Original file line numberDiff line numberDiff line change
@@ -77,7 +77,10 @@ extern void pgwin32_register_deadchild_callback(HANDLE procHandle, DWORD procId)
7777
extern PGDLLIMPORT struct ClientSocket *MyClientSocket;
7878

7979
/* prototypes for functions in launch_backend.c */
80-
extern pid_t postmaster_child_launch(BackendType child_type, char *startup_data, size_t startup_data_len, struct ClientSocket *sock);
80+
extern pid_t postmaster_child_launch(BackendType child_type,
81+
char *startup_data,
82+
size_t startup_data_len,
83+
struct ClientSocket *client_sock);
8184
const char *PostmasterChildName(BackendType child_type);
8285
#ifdef EXEC_BACKEND
8386
extern void SubPostmasterMain(int argc, char *argv[]) pg_attribute_noreturn();

src/include/storage/bufmgr.h

+1-1
Original file line numberDiff line numberDiff line change
@@ -220,7 +220,7 @@ extern bool StartReadBuffer(ReadBuffersOperation *operation,
220220
int flags);
221221
extern bool StartReadBuffers(ReadBuffersOperation *operation,
222222
Buffer *buffers,
223-
BlockNumber blocknum,
223+
BlockNumber blockNum,
224224
int *nblocks,
225225
int flags);
226226
extern void WaitReadBuffers(ReadBuffersOperation *operation);

src/include/storage/fd.h

+3-3
Original file line numberDiff line numberDiff line change
@@ -107,8 +107,8 @@ extern File PathNameOpenFilePerm(const char *fileName, int fileFlags, mode_t fil
107107
extern File OpenTemporaryFile(bool interXact);
108108
extern void FileClose(File file);
109109
extern int FilePrefetch(File file, off_t offset, off_t amount, uint32 wait_event_info);
110-
extern ssize_t FileReadV(File file, const struct iovec *ioc, int iovcnt, off_t offset, uint32 wait_event_info);
111-
extern ssize_t FileWriteV(File file, const struct iovec *ioc, int iovcnt, off_t offset, uint32 wait_event_info);
110+
extern ssize_t FileReadV(File file, const struct iovec *iov, int iovcnt, off_t offset, uint32 wait_event_info);
111+
extern ssize_t FileWriteV(File file, const struct iovec *iov, int iovcnt, off_t offset, uint32 wait_event_info);
112112
extern int FileSync(File file, uint32 wait_event_info);
113113
extern int FileZero(File file, off_t offset, off_t amount, uint32 wait_event_info);
114114
extern int FileFallocate(File file, off_t offset, off_t amount, uint32 wait_event_info);
@@ -182,7 +182,7 @@ extern int pg_fsync(int fd);
182182
extern int pg_fsync_no_writethrough(int fd);
183183
extern int pg_fsync_writethrough(int fd);
184184
extern int pg_fdatasync(int fd);
185-
extern bool pg_file_exists(const char *fname);
185+
extern bool pg_file_exists(const char *name);
186186
extern void pg_flush_data(int fd, off_t offset, off_t nbytes);
187187
extern int pg_truncate(const char *path, off_t length);
188188
extern void fsync_fname(const char *fname, bool isdir);

src/include/storage/read_stream.h

+1-1
Original file line numberDiff line numberDiff line change
@@ -56,7 +56,7 @@ extern ReadStream *read_stream_begin_relation(int flags,
5656
ReadStreamBlockNumberCB callback,
5757
void *callback_private_data,
5858
size_t per_buffer_data_size);
59-
extern Buffer read_stream_next_buffer(ReadStream *stream, void **per_buffer_private);
59+
extern Buffer read_stream_next_buffer(ReadStream *stream, void **per_buffer_data);
6060
extern void read_stream_reset(ReadStream *stream);
6161
extern void read_stream_end(ReadStream *stream);
6262

src/include/storage/smgr.h

+2-2
Original file line numberDiff line numberDiff line change
@@ -94,10 +94,10 @@ extern bool smgrprefetch(SMgrRelation reln, ForkNumber forknum,
9494
BlockNumber blocknum, int nblocks);
9595
extern void smgrreadv(SMgrRelation reln, ForkNumber forknum,
9696
BlockNumber blocknum,
97-
void **buffer, BlockNumber nblocks);
97+
void **buffers, BlockNumber nblocks);
9898
extern void smgrwritev(SMgrRelation reln, ForkNumber forknum,
9999
BlockNumber blocknum,
100-
const void **buffer, BlockNumber nblocks,
100+
const void **buffers, BlockNumber nblocks,
101101
bool skipFsync);
102102
extern void smgrwriteback(SMgrRelation reln, ForkNumber forknum,
103103
BlockNumber blocknum, BlockNumber nblocks);

src/include/utils/guc.h

+2-2
Original file line numberDiff line numberDiff line change
@@ -402,8 +402,8 @@ extern void AlterSystemSetConfigFile(AlterSystemStmt *altersysstmt);
402402
extern char *GetConfigOptionByName(const char *name, const char **varname,
403403
bool missing_ok);
404404

405-
extern void TransformGUCArray(ArrayType *array, List **configNames,
406-
List **configValues);
405+
extern void TransformGUCArray(ArrayType *array, List **names,
406+
List **values);
407407
extern void ProcessGUCArray(ArrayType *array,
408408
GucContext context, GucSource source, GucAction action);
409409
extern ArrayType *GUCArrayAdd(ArrayType *array, const char *name, const char *value);

src/include/utils/jsonpath.h

+1-1
Original file line numberDiff line numberDiff line change
@@ -295,7 +295,7 @@ typedef struct JsonPathVariable
295295

296296

297297
/* SQL/JSON query functions */
298-
extern bool JsonPathExists(Datum jb, JsonPath *path, bool *error, List *vars);
298+
extern bool JsonPathExists(Datum jb, JsonPath *jp, bool *error, List *vars);
299299
extern Datum JsonPathQuery(Datum jb, JsonPath *jp, JsonWrapper wrapper,
300300
bool *empty, bool *error, List *vars,
301301
const char *column_name);

src/include/utils/pg_locale.h

+2-2
Original file line numberDiff line numberDiff line change
@@ -117,8 +117,8 @@ extern size_t pg_strxfrm_prefix(char *dest, const char *src, size_t destsize,
117117
extern size_t pg_strnxfrm_prefix(char *dest, size_t destsize, const char *src,
118118
size_t srclen, pg_locale_t locale);
119119

120-
extern int builtin_locale_encoding(const char *loc_str);
121-
extern const char *builtin_validate_locale(int encoding, const char *loc_str);
120+
extern int builtin_locale_encoding(const char *locale);
121+
extern const char *builtin_validate_locale(int encoding, const char *locale);
122122
extern void icu_validate_locale(const char *loc_str);
123123
extern char *icu_language_tag(const char *loc_str, int elevel);
124124

src/include/utils/resowner.h

+2-2
Original file line numberDiff line numberDiff line change
@@ -146,8 +146,8 @@ extern void ResourceOwnerNewParent(ResourceOwner owner,
146146
ResourceOwner newparent);
147147

148148
extern void ResourceOwnerEnlarge(ResourceOwner owner);
149-
extern void ResourceOwnerRemember(ResourceOwner owner, Datum res, const ResourceOwnerDesc *kind);
150-
extern void ResourceOwnerForget(ResourceOwner owner, Datum res, const ResourceOwnerDesc *kind);
149+
extern void ResourceOwnerRemember(ResourceOwner owner, Datum value, const ResourceOwnerDesc *kind);
150+
extern void ResourceOwnerForget(ResourceOwner owner, Datum value, const ResourceOwnerDesc *kind);
151151

152152
extern void ResourceOwnerReleaseAllOfKind(ResourceOwner owner, const ResourceOwnerDesc *kind);
153153

src/include/utils/tuplesort.h

+1-1
Original file line numberDiff line numberDiff line change
@@ -455,7 +455,7 @@ extern void tuplesort_putheaptuple(Tuplesortstate *state, HeapTuple tup);
455455
extern void tuplesort_putindextuplevalues(Tuplesortstate *state,
456456
Relation rel, ItemPointer self,
457457
const Datum *values, const bool *isnull);
458-
extern void tuplesort_putbrintuple(Tuplesortstate *state, BrinTuple *tup, Size len);
458+
extern void tuplesort_putbrintuple(Tuplesortstate *state, BrinTuple *tuple, Size size);
459459
extern void tuplesort_putdatum(Tuplesortstate *state, Datum val,
460460
bool isNull);
461461

0 commit comments

Comments
 (0)