Movatterモバイル変換


[0]ホーム

URL:


Skip to content

Navigation Menu

Sign in
Appearance settings

Search code, repositories, users, issues, pull requests...

Provide feedback

We read every piece of feedback, and take your input very seriously.

Saved searches

Use saved searches to filter your results more quickly

Sign up
Appearance settings

Commitbfcf1b3

Browse files
Harmonize parameter names in storage and AM code.
Make sure that function declarations use names that exactly match thecorresponding names from function definitions in storage, catalog,access method, executor, and logical replication code, as well as inmiscellaneous utility/library code.Like other recent commits that cleaned up function parameter names, thiscommit was written with help from clang-tidy. Later commits will do thesame for other parts of the codebase.Author: Peter Geoghegan <pg@bowt.ie>Reviewed-By: David Rowley <dgrowleyml@gmail.com>Discussion:https://postgr.es/m/CAH2-WznJt9CMM9KJTMjJh_zbL5hD9oX44qdJ4aqZtjFi-zA3Tg@mail.gmail.com
1 parentc47885b commitbfcf1b3

File tree

80 files changed

+228
-218
lines changed

Some content is hidden

Large Commits have some content hidden by default. Use the searchbox below for content that may be hidden.

80 files changed

+228
-218
lines changed

‎src/backend/access/brin/brin_minmax_multi.c

Lines changed: 2 additions & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -223,7 +223,8 @@ typedef struct SerializedRanges
223223

224224
staticSerializedRanges*brin_range_serialize(Ranges*range);
225225

226-
staticRanges*brin_range_deserialize(intmaxvalues,SerializedRanges*range);
226+
staticRanges*brin_range_deserialize(intmaxvalues,
227+
SerializedRanges*serialized);
227228

228229

229230
/*

‎src/backend/access/common/reloptions.c

Lines changed: 6 additions & 6 deletions
Original file line numberDiff line numberDiff line change
@@ -733,11 +733,11 @@ add_reloption(relopt_gen *newoption)
733733
* 'relopt_struct_size'.
734734
*/
735735
void
736-
init_local_reloptions(local_relopts*opts,Sizerelopt_struct_size)
736+
init_local_reloptions(local_relopts*relopts,Sizerelopt_struct_size)
737737
{
738-
opts->options=NIL;
739-
opts->validators=NIL;
740-
opts->relopt_struct_size=relopt_struct_size;
738+
relopts->options=NIL;
739+
relopts->validators=NIL;
740+
relopts->relopt_struct_size=relopt_struct_size;
741741
}
742742

743743
/*
@@ -746,9 +746,9 @@ init_local_reloptions(local_relopts *opts, Size relopt_struct_size)
746746
*build_local_reloptions().
747747
*/
748748
void
749-
register_reloptions_validator(local_relopts*opts,relopts_validatorvalidator)
749+
register_reloptions_validator(local_relopts*relopts,relopts_validatorvalidator)
750750
{
751-
opts->validators=lappend(opts->validators,validator);
751+
relopts->validators=lappend(relopts->validators,validator);
752752
}
753753

754754
/*

‎src/backend/access/gin/ginpostinglist.c

Lines changed: 2 additions & 2 deletions
Original file line numberDiff line numberDiff line change
@@ -281,11 +281,11 @@ ginCompressPostingList(const ItemPointer ipd, int nipd, int maxsize,
281281
* The number of items is returned in *ndecoded.
282282
*/
283283
ItemPointer
284-
ginPostingListDecode(GinPostingList*plist,int*ndecoded)
284+
ginPostingListDecode(GinPostingList*plist,int*ndecoded_out)
285285
{
286286
returnginPostingListDecodeAllSegments(plist,
287287
SizeOfGinPostingList(plist),
288-
ndecoded);
288+
ndecoded_out);
289289
}
290290

291291
/*

‎src/backend/access/gist/gistbuild.c

Lines changed: 3 additions & 2 deletions
Original file line numberDiff line numberDiff line change
@@ -162,7 +162,7 @@ static BlockNumber gistbufferinginserttuples(GISTBuildState *buildstate,
162162
BlockNumberparentblk,OffsetNumberdownlinkoffnum);
163163
staticBuffergistBufferingFindCorrectParent(GISTBuildState*buildstate,
164164
BlockNumberchildblkno,intlevel,
165-
BlockNumber*parentblk,
165+
BlockNumber*parentblkno,
166166
OffsetNumber*downlinkoffnum);
167167
staticvoidgistProcessEmptyingQueue(GISTBuildState*buildstate);
168168
staticvoidgistEmptyAllBuffers(GISTBuildState*buildstate);
@@ -171,7 +171,8 @@ static intgistGetMaxLevel(Relation index);
171171
staticvoidgistInitParentMap(GISTBuildState*buildstate);
172172
staticvoidgistMemorizeParent(GISTBuildState*buildstate,BlockNumberchild,
173173
BlockNumberparent);
174-
staticvoidgistMemorizeAllDownlinks(GISTBuildState*buildstate,Bufferparent);
174+
staticvoidgistMemorizeAllDownlinks(GISTBuildState*buildstate,
175+
Bufferparentbuf);
175176
staticBlockNumbergistGetParent(GISTBuildState*buildstate,BlockNumberchild);
176177

177178

‎src/backend/access/gist/gistbuildbuffers.c

Lines changed: 2 additions & 2 deletions
Original file line numberDiff line numberDiff line change
@@ -31,9 +31,9 @@ static void gistLoadNodeBuffer(GISTBuildBuffers *gfbb,
3131
staticvoidgistUnloadNodeBuffer(GISTBuildBuffers*gfbb,
3232
GISTNodeBuffer*nodeBuffer);
3333
staticvoidgistPlaceItupToPage(GISTNodeBufferPage*pageBuffer,
34-
IndexTupleitem);
34+
IndexTupleitup);
3535
staticvoidgistGetItupFromPage(GISTNodeBufferPage*pageBuffer,
36-
IndexTuple*item);
36+
IndexTuple*itup);
3737
staticlonggistBuffersGetFreeBlock(GISTBuildBuffers*gfbb);
3838
staticvoidgistBuffersReleaseBlock(GISTBuildBuffers*gfbb,longblocknum);
3939

‎src/backend/access/gist/gistvacuum.c

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -49,7 +49,7 @@ static void gistvacuumpage(GistVacState *vstate, BlockNumber blkno,
4949
staticvoidgistvacuum_delete_empty_pages(IndexVacuumInfo*info,
5050
GistVacState*vstate);
5151
staticboolgistdeletepage(IndexVacuumInfo*info,IndexBulkDeleteResult*stats,
52-
Bufferbuffer,OffsetNumberdownlink,
52+
BufferparentBuffer,OffsetNumberdownlink,
5353
BufferleafBuffer);
5454

5555
/*

‎src/backend/access/transam/generic_xlog.c

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -69,7 +69,7 @@ struct GenericXLogState
6969
};
7070

7171
staticvoidwriteFragment(PageData*pageData,OffsetNumberoffset,
72-
OffsetNumberlen,constchar*data);
72+
OffsetNumberlength,constchar*data);
7373
staticvoidcomputeRegionDelta(PageData*pageData,
7474
constchar*curpage,constchar*targetpage,
7575
inttargetStart,inttargetEnd,

‎src/backend/access/transam/xact.c

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -354,7 +354,7 @@ static void AtSubStart_Memory(void);
354354
staticvoidAtSubStart_ResourceOwner(void);
355355

356356
staticvoidShowTransactionState(constchar*str);
357-
staticvoidShowTransactionStateRec(constchar*str,TransactionStatestate);
357+
staticvoidShowTransactionStateRec(constchar*str,TransactionStates);
358358
staticconstchar*BlockStateAsString(TBlockStateblockState);
359359
staticconstchar*TransStateAsString(TransStatestate);
360360

‎src/backend/access/transam/xlog.c

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -648,7 +648,7 @@ static void XLogReportParameters(void);
648648
staticintLocalSetXLogInsertAllowed(void);
649649
staticvoidCreateEndOfRecoveryRecord(void);
650650
staticXLogRecPtrCreateOverwriteContrecordRecord(XLogRecPtraborted_lsn,
651-
XLogRecPtrmissingContrecPtr,
651+
XLogRecPtrpagePtr,
652652
TimeLineIDnewTLI);
653653
staticvoidCheckPointGuts(XLogRecPtrcheckPointRedo,intflags);
654654
staticvoidKeepLogSeg(XLogRecPtrrecptr,XLogSegNo*logSegNo);

‎src/backend/access/transam/xloginsert.c

Lines changed: 9 additions & 9 deletions
Original file line numberDiff line numberDiff line change
@@ -1094,7 +1094,7 @@ XLogSaveBufferForHint(Buffer buffer, bool buffer_std)
10941094
* the unused space to be left out from the WAL record, making it smaller.
10951095
*/
10961096
XLogRecPtr
1097-
log_newpage(RelFileLocator*rlocator,ForkNumberforkNum,BlockNumberblkno,
1097+
log_newpage(RelFileLocator*rlocator,ForkNumberforknum,BlockNumberblkno,
10981098
Pagepage,boolpage_std)
10991099
{
11001100
intflags;
@@ -1105,7 +1105,7 @@ log_newpage(RelFileLocator *rlocator, ForkNumber forkNum, BlockNumber blkno,
11051105
flags |=REGBUF_STANDARD;
11061106

11071107
XLogBeginInsert();
1108-
XLogRegisterBlock(0,rlocator,forkNum,blkno,page,flags);
1108+
XLogRegisterBlock(0,rlocator,forknum,blkno,page,flags);
11091109
recptr=XLogInsert(RM_XLOG_ID,XLOG_FPI);
11101110

11111111
/*
@@ -1126,7 +1126,7 @@ log_newpage(RelFileLocator *rlocator, ForkNumber forkNum, BlockNumber blkno,
11261126
* because we can write multiple pages in a single WAL record.
11271127
*/
11281128
void
1129-
log_newpages(RelFileLocator*rlocator,ForkNumberforkNum,intnum_pages,
1129+
log_newpages(RelFileLocator*rlocator,ForkNumberforknum,intnum_pages,
11301130
BlockNumber*blknos,Page*pages,boolpage_std)
11311131
{
11321132
intflags;
@@ -1156,7 +1156,7 @@ log_newpages(RelFileLocator *rlocator, ForkNumber forkNum, int num_pages,
11561156
nbatch=0;
11571157
while (nbatch<XLR_MAX_BLOCK_ID&&i<num_pages)
11581158
{
1159-
XLogRegisterBlock(nbatch,rlocator,forkNum,blknos[i],pages[i],flags);
1159+
XLogRegisterBlock(nbatch,rlocator,forknum,blknos[i],pages[i],flags);
11601160
i++;
11611161
nbatch++;
11621162
}
@@ -1192,15 +1192,15 @@ log_newpage_buffer(Buffer buffer, bool page_std)
11921192
{
11931193
Pagepage=BufferGetPage(buffer);
11941194
RelFileLocatorrlocator;
1195-
ForkNumberforkNum;
1195+
ForkNumberforknum;
11961196
BlockNumberblkno;
11971197

11981198
/* Shared buffers should be modified in a critical section. */
11991199
Assert(CritSectionCount>0);
12001200

1201-
BufferGetTag(buffer,&rlocator,&forkNum,&blkno);
1201+
BufferGetTag(buffer,&rlocator,&forknum,&blkno);
12021202

1203-
returnlog_newpage(&rlocator,forkNum,blkno,page,page_std);
1203+
returnlog_newpage(&rlocator,forknum,blkno,page,page_std);
12041204
}
12051205

12061206
/*
@@ -1221,7 +1221,7 @@ log_newpage_buffer(Buffer buffer, bool page_std)
12211221
* cause a deadlock through some other means.
12221222
*/
12231223
void
1224-
log_newpage_range(Relationrel,ForkNumberforkNum,
1224+
log_newpage_range(Relationrel,ForkNumberforknum,
12251225
BlockNumberstartblk,BlockNumberendblk,
12261226
boolpage_std)
12271227
{
@@ -1253,7 +1253,7 @@ log_newpage_range(Relation rel, ForkNumber forkNum,
12531253
nbufs=0;
12541254
while (nbufs<XLR_MAX_BLOCK_ID&&blkno<endblk)
12551255
{
1256-
Bufferbuf=ReadBufferExtended(rel,forkNum,blkno,
1256+
Bufferbuf=ReadBufferExtended(rel,forknum,blkno,
12571257
RBM_NORMAL,NULL);
12581258

12591259
LockBuffer(buf,BUFFER_LOCK_EXCLUSIVE);

‎src/backend/access/transam/xlogreader.c

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -47,7 +47,7 @@ static bool allocate_recordbuf(XLogReaderState *state, uint32 reclength);
4747
staticintReadPageInternal(XLogReaderState*state,XLogRecPtrpageptr,
4848
intreqLen);
4949
staticvoidXLogReaderInvalReadState(XLogReaderState*state);
50-
staticXLogPageReadResultXLogDecodeNextRecord(XLogReaderState*state,boolnon_blocking);
50+
staticXLogPageReadResultXLogDecodeNextRecord(XLogReaderState*state,boolnonblocking);
5151
staticboolValidXLogRecordHeader(XLogReaderState*state,XLogRecPtrRecPtr,
5252
XLogRecPtrPrevRecPtr,XLogRecord*record,boolrandAccess);
5353
staticboolValidXLogRecord(XLogReaderState*state,XLogRecord*record,

‎src/backend/catalog/aclchk.c

Lines changed: 11 additions & 11 deletions
Original file line numberDiff line numberDiff line change
@@ -104,17 +104,17 @@ typedef struct
104104
boolbinary_upgrade_record_init_privs= false;
105105

106106
staticvoidExecGrantStmt_oids(InternalGrant*istmt);
107-
staticvoidExecGrant_Relation(InternalGrant*grantStmt);
108-
staticvoidExecGrant_Database(InternalGrant*grantStmt);
109-
staticvoidExecGrant_Fdw(InternalGrant*grantStmt);
110-
staticvoidExecGrant_ForeignServer(InternalGrant*grantStmt);
111-
staticvoidExecGrant_Function(InternalGrant*grantStmt);
112-
staticvoidExecGrant_Language(InternalGrant*grantStmt);
113-
staticvoidExecGrant_Largeobject(InternalGrant*grantStmt);
114-
staticvoidExecGrant_Namespace(InternalGrant*grantStmt);
115-
staticvoidExecGrant_Tablespace(InternalGrant*grantStmt);
116-
staticvoidExecGrant_Type(InternalGrant*grantStmt);
117-
staticvoidExecGrant_Parameter(InternalGrant*grantStmt);
107+
staticvoidExecGrant_Relation(InternalGrant*istmt);
108+
staticvoidExecGrant_Database(InternalGrant*istmt);
109+
staticvoidExecGrant_Fdw(InternalGrant*istmt);
110+
staticvoidExecGrant_ForeignServer(InternalGrant*istmt);
111+
staticvoidExecGrant_Function(InternalGrant*istmt);
112+
staticvoidExecGrant_Language(InternalGrant*istmt);
113+
staticvoidExecGrant_Largeobject(InternalGrant*istmt);
114+
staticvoidExecGrant_Namespace(InternalGrant*istmt);
115+
staticvoidExecGrant_Tablespace(InternalGrant*istmt);
116+
staticvoidExecGrant_Type(InternalGrant*istmt);
117+
staticvoidExecGrant_Parameter(InternalGrant*istmt);
118118

119119
staticvoidSetDefaultACLsInSchemas(InternalDefaultACL*iacls,List*nspnames);
120120
staticvoidSetDefaultACL(InternalDefaultACL*iacls);

‎src/backend/catalog/namespace.c

Lines changed: 6 additions & 6 deletions
Original file line numberDiff line numberDiff line change
@@ -3644,7 +3644,7 @@ PopOverrideSearchPath(void)
36443644
* database's encoding.
36453645
*/
36463646
Oid
3647-
get_collation_oid(List*name,boolmissing_ok)
3647+
get_collation_oid(List*collname,boolmissing_ok)
36483648
{
36493649
char*schemaname;
36503650
char*collation_name;
@@ -3654,7 +3654,7 @@ get_collation_oid(List *name, bool missing_ok)
36543654
ListCell*l;
36553655

36563656
/* deconstruct the name list */
3657-
DeconstructQualifiedName(name,&schemaname,&collation_name);
3657+
DeconstructQualifiedName(collname,&schemaname,&collation_name);
36583658

36593659
if (schemaname)
36603660
{
@@ -3690,15 +3690,15 @@ get_collation_oid(List *name, bool missing_ok)
36903690
ereport(ERROR,
36913691
(errcode(ERRCODE_UNDEFINED_OBJECT),
36923692
errmsg("collation \"%s\" for encoding \"%s\" does not exist",
3693-
NameListToString(name),GetDatabaseEncodingName())));
3693+
NameListToString(collname),GetDatabaseEncodingName())));
36943694
returnInvalidOid;
36953695
}
36963696

36973697
/*
36983698
* get_conversion_oid - find a conversion by possibly qualified name
36993699
*/
37003700
Oid
3701-
get_conversion_oid(List*name,boolmissing_ok)
3701+
get_conversion_oid(List*conname,boolmissing_ok)
37023702
{
37033703
char*schemaname;
37043704
char*conversion_name;
@@ -3707,7 +3707,7 @@ get_conversion_oid(List *name, bool missing_ok)
37073707
ListCell*l;
37083708

37093709
/* deconstruct the name list */
3710-
DeconstructQualifiedName(name,&schemaname,&conversion_name);
3710+
DeconstructQualifiedName(conname,&schemaname,&conversion_name);
37113711

37123712
if (schemaname)
37133713
{
@@ -3745,7 +3745,7 @@ get_conversion_oid(List *name, bool missing_ok)
37453745
ereport(ERROR,
37463746
(errcode(ERRCODE_UNDEFINED_OBJECT),
37473747
errmsg("conversion \"%s\" does not exist",
3748-
NameListToString(name))));
3748+
NameListToString(conname))));
37493749
returnconoid;
37503750
}
37513751

‎src/backend/commands/dbcommands.c

Lines changed: 4 additions & 4 deletions
Original file line numberDiff line numberDiff line change
@@ -125,9 +125,9 @@ static bool have_createdb_privilege(void);
125125
staticvoidremove_dbtablespaces(Oiddb_id);
126126
staticboolcheck_db_file_conflict(Oiddb_id);
127127
staticinterrdetail_busy_db(intnotherbackends,intnpreparedxacts);
128-
staticvoidCreateDatabaseUsingWalLog(Oidsrc_dboid,Oiddboid,Oidsrc_tsid,
128+
staticvoidCreateDatabaseUsingWalLog(Oidsrc_dboid,Oiddst_dboid,Oidsrc_tsid,
129129
Oiddst_tsid);
130-
staticList*ScanSourceDatabasePgClass(Oidsrctbid,Oidsrcdbid,char*srcpath);
130+
staticList*ScanSourceDatabasePgClass(Oidtbid,Oiddbid,char*srcpath);
131131
staticList*ScanSourceDatabasePgClassPage(Pagepage,Bufferbuf,Oidtbid,
132132
Oiddbid,char*srcpath,
133133
List*rlocatorlist,Snapshotsnapshot);
@@ -136,8 +136,8 @@ static CreateDBRelInfo *ScanSourceDatabasePgClassTuple(HeapTupleData *tuple,
136136
char*srcpath);
137137
staticvoidCreateDirAndVersionFile(char*dbpath,Oiddbid,Oidtsid,
138138
boolisRedo);
139-
staticvoidCreateDatabaseUsingFileCopy(Oidsrc_dboid,Oiddboid,Oidsrc_tsid,
140-
Oiddst_tsid);
139+
staticvoidCreateDatabaseUsingFileCopy(Oidsrc_dboid,Oiddst_dboid,
140+
Oidsrc_tsid,Oiddst_tsid);
141141
staticvoidrecovery_create_dbdir(char*path,boolonly_tblspc);
142142

143143
/*

‎src/backend/executor/execIndexing.c

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -130,7 +130,7 @@ static bool check_exclusion_or_unique_constraint(Relation heap, Relation index,
130130
Datum*values,bool*isnull,
131131
EState*estate,boolnewIndex,
132132
CEOUC_WAIT_MODEwaitMode,
133-
boolerrorOK,
133+
boolviolationOK,
134134
ItemPointerconflictTid);
135135

136136
staticboolindex_recheck_constraint(Relationindex,Oid*constr_procs,

‎src/backend/executor/execParallel.c

Lines changed: 2 additions & 2 deletions
Original file line numberDiff line numberDiff line change
@@ -126,9 +126,9 @@ typedef struct ExecParallelInitializeDSMContext
126126

127127
/* Helper functions that run in the parallel leader. */
128128
staticchar*ExecSerializePlan(Plan*plan,EState*estate);
129-
staticboolExecParallelEstimate(PlanState*node,
129+
staticboolExecParallelEstimate(PlanState*planstate,
130130
ExecParallelEstimateContext*e);
131-
staticboolExecParallelInitializeDSM(PlanState*node,
131+
staticboolExecParallelInitializeDSM(PlanState*planstate,
132132
ExecParallelInitializeDSMContext*d);
133133
staticshm_mq_handle**ExecParallelSetupTupleQueues(ParallelContext*pcxt,
134134
boolreinitialize);

‎src/backend/executor/nodeAgg.c

Lines changed: 5 additions & 6 deletions
Original file line numberDiff line numberDiff line change
@@ -396,7 +396,7 @@ static void prepare_projection_slot(AggState *aggstate,
396396
TupleTableSlot*slot,
397397
intcurrentSet);
398398
staticvoidfinalize_aggregates(AggState*aggstate,
399-
AggStatePerAggperagg,
399+
AggStatePerAggperaggs,
400400
AggStatePerGrouppergroup);
401401
staticTupleTableSlot*project_aggregates(AggState*aggstate);
402402
staticvoidfind_cols(AggState*aggstate,Bitmapset**aggregated,
@@ -407,12 +407,11 @@ static void build_hash_table(AggState *aggstate, int setno, long nbuckets);
407407
staticvoidhashagg_recompile_expressions(AggState*aggstate,boolminslot,
408408
boolnullcheck);
409409
staticlonghash_choose_num_buckets(doublehashentrysize,
410-
longestimated_nbuckets,
411-
Sizememory);
410+
longngroups,Sizememory);
412411
staticinthash_choose_num_partitions(doubleinput_groups,
413412
doublehashentrysize,
414413
intused_bits,
415-
int*log2_npartittions);
414+
int*log2_npartitions);
416415
staticvoidinitialize_hash_entry(AggState*aggstate,
417416
TupleHashTablehashtable,
418417
TupleHashEntryentry);
@@ -432,11 +431,11 @@ static HashAggBatch *hashagg_batch_new(LogicalTape *input_tape, int setno,
432431
int64input_tuples,doubleinput_card,
433432
intused_bits);
434433
staticMinimalTuplehashagg_batch_read(HashAggBatch*batch,uint32*hashp);
435-
staticvoidhashagg_spill_init(HashAggSpill*spill,LogicalTapeSet*lts,
434+
staticvoidhashagg_spill_init(HashAggSpill*spill,LogicalTapeSet*tapeset,
436435
intused_bits,doubleinput_groups,
437436
doublehashentrysize);
438437
staticSizehashagg_spill_tuple(AggState*aggstate,HashAggSpill*spill,
439-
TupleTableSlot*slot,uint32hash);
438+
TupleTableSlot*inputslot,uint32hash);
440439
staticvoidhashagg_spill_finish(AggState*aggstate,HashAggSpill*spill,
441440
intsetno);
442441
staticDatumGetAggInitVal(DatumtextInitVal,Oidtranstype);

‎src/backend/executor/nodeHash.c

Lines changed: 3 additions & 3 deletions
Original file line numberDiff line numberDiff line change
@@ -62,9 +62,9 @@ static HashJoinTuple ExecParallelHashTupleAlloc(HashJoinTable hashtable,
6262
dsa_pointer*shared);
6363
staticvoidMultiExecPrivateHash(HashState*node);
6464
staticvoidMultiExecParallelHash(HashState*node);
65-
staticinlineHashJoinTupleExecParallelHashFirstTuple(HashJoinTabletable,
65+
staticinlineHashJoinTupleExecParallelHashFirstTuple(HashJoinTablehashtable,
6666
intbucketno);
67-
staticinlineHashJoinTupleExecParallelHashNextTuple(HashJoinTabletable,
67+
staticinlineHashJoinTupleExecParallelHashNextTuple(HashJoinTablehashtable,
6868
HashJoinTupletuple);
6969
staticinlinevoidExecParallelHashPushTuple(dsa_pointer_atomic*head,
7070
HashJoinTupletuple,
@@ -73,7 +73,7 @@ static void ExecParallelHashJoinSetUpBatches(HashJoinTable hashtable, int nbatch
7373
staticvoidExecParallelHashEnsureBatchAccessors(HashJoinTablehashtable);
7474
staticvoidExecParallelHashRepartitionFirst(HashJoinTablehashtable);
7575
staticvoidExecParallelHashRepartitionRest(HashJoinTablehashtable);
76-
staticHashMemoryChunkExecParallelHashPopChunkQueue(HashJoinTabletable,
76+
staticHashMemoryChunkExecParallelHashPopChunkQueue(HashJoinTablehashtable,
7777
dsa_pointer*shared);
7878
staticboolExecParallelHashTuplePrealloc(HashJoinTablehashtable,
7979
intbatchno,

0 commit comments

Comments
 (0)

[8]ページ先頭

©2009-2025 Movatter.jp