diff options
Diffstat (limited to 'src/backend/executor')
-rw-r--r-- | src/backend/executor/execExpr.c | 6 | ||||
-rw-r--r-- | src/backend/executor/execExprInterp.c | 2 | ||||
-rw-r--r-- | src/backend/executor/execMain.c | 2 | ||||
-rw-r--r-- | src/backend/executor/execParallel.c | 4 | ||||
-rw-r--r-- | src/backend/executor/execPartition.c | 24 | ||||
-rw-r--r-- | src/backend/executor/execReplication.c | 22 | ||||
-rw-r--r-- | src/backend/executor/execScan.c | 3 | ||||
-rw-r--r-- | src/backend/executor/execTuples.c | 33 | ||||
-rw-r--r-- | src/backend/executor/functions.c | 4 | ||||
-rw-r--r-- | src/backend/executor/nodeAgg.c | 2 | ||||
-rw-r--r-- | src/backend/executor/nodeGatherMerge.c | 4 | ||||
-rw-r--r-- | src/backend/executor/nodeHashjoin.c | 2 | ||||
-rw-r--r-- | src/backend/executor/nodeIndexonlyscan.c | 6 | ||||
-rw-r--r-- | src/backend/executor/nodeIndexscan.c | 2 | ||||
-rw-r--r-- | src/backend/executor/nodeLockRows.c | 2 | ||||
-rw-r--r-- | src/backend/executor/nodeModifyTable.c | 6 | ||||
-rw-r--r-- | src/backend/executor/nodeSeqscan.c | 4 | ||||
-rw-r--r-- | src/backend/executor/nodeSubplan.c | 2 | ||||
-rw-r--r-- | src/backend/executor/nodeSubqueryscan.c | 1 |
19 files changed, 68 insertions, 63 deletions
diff --git a/src/backend/executor/execExpr.c b/src/backend/executor/execExpr.c index 0a7b2b8f477..5d64471eeda 100644 --- a/src/backend/executor/execExpr.c +++ b/src/backend/executor/execExpr.c @@ -2367,10 +2367,10 @@ get_last_attnums_walker(Node *node, LastAttnumInfo *info) static void ExecComputeSlotInfo(ExprState *state, ExprEvalStep *op) { - PlanState *parent = state->parent; + PlanState *parent = state->parent; TupleDesc desc = NULL; const TupleTableSlotOps *tts_ops = NULL; - bool isfixed = false; + bool isfixed = false; if (op->d.fetch.known_desc != NULL) { @@ -3313,7 +3313,7 @@ ExecBuildAggTransCall(ExprState *state, AggState *aggstate, */ ExprState * ExecBuildGroupingEqual(TupleDesc ldesc, TupleDesc rdesc, - const TupleTableSlotOps * lops, const TupleTableSlotOps * rops, + const TupleTableSlotOps *lops, const TupleTableSlotOps *rops, int numCols, const AttrNumber *keyColIdx, const Oid *eqfunctions, diff --git a/src/backend/executor/execExprInterp.c b/src/backend/executor/execExprInterp.c index a018925d4ed..612a88456eb 100644 --- a/src/backend/executor/execExprInterp.c +++ b/src/backend/executor/execExprInterp.c @@ -4038,7 +4038,7 @@ void ExecEvalSysVar(ExprState *state, ExprEvalStep *op, ExprContext *econtext, TupleTableSlot *slot) { - Datum d; + Datum d; /* slot_getsysattr has sufficient defenses against bad attnums */ d = slot_getsysattr(slot, diff --git a/src/backend/executor/execMain.c b/src/backend/executor/execMain.c index ed7c0606bf1..44e4a6d104c 100644 --- a/src/backend/executor/execMain.c +++ b/src/backend/executor/execMain.c @@ -2551,7 +2551,7 @@ EvalPlanQualSlot(EPQState *epqstate, if (relation) *slot = table_slot_create(relation, - &epqstate->estate->es_tupleTable); + &epqstate->estate->es_tupleTable); else *slot = ExecAllocTableSlot(&epqstate->estate->es_tupleTable, epqstate->origslot->tts_tupleDescriptor, diff --git a/src/backend/executor/execParallel.c b/src/backend/executor/execParallel.c index 3d4b01cb4d6..da9074c54c9 100644 --- a/src/backend/executor/execParallel.c +++ b/src/backend/executor/execParallel.c @@ -1058,7 +1058,7 @@ ExecParallelRetrieveJitInstrumentation(PlanState *planstate, * instrumentation in per-query context. */ ibytes = offsetof(SharedJitInstrumentation, jit_instr) - + mul_size(shared_jit->num_workers, sizeof(JitInstrumentation)); + + mul_size(shared_jit->num_workers, sizeof(JitInstrumentation)); planstate->worker_jit_instrument = MemoryContextAlloc(planstate->state->es_query_cxt, ibytes); @@ -1133,7 +1133,7 @@ ExecParallelCleanup(ParallelExecutorInfo *pei) /* Accumulate JIT instrumentation, if any. */ if (pei->jit_instrumentation) ExecParallelRetrieveJitInstrumentation(pei->planstate, - pei->jit_instrumentation); + pei->jit_instrumentation); /* Free any serialized parameters. */ if (DsaPointerIsValid(pei->param_exec)) diff --git a/src/backend/executor/execPartition.c b/src/backend/executor/execPartition.c index 6cdbb9db421..73ba298c5da 100644 --- a/src/backend/executor/execPartition.c +++ b/src/backend/executor/execPartition.c @@ -145,12 +145,12 @@ typedef struct PartitionDispatchData TupleTableSlot *tupslot; AttrNumber *tupmap; int indexes[FLEXIBLE_ARRAY_MEMBER]; -} PartitionDispatchData; +} PartitionDispatchData; /* struct to hold result relations coming from UPDATE subplans */ typedef struct SubplanResultRelHashElem { - Oid relid; /* hash key -- must be first */ + Oid relid; /* hash key -- must be first */ ResultRelInfo *rri; } SubplanResultRelHashElem; @@ -375,7 +375,7 @@ ExecFindPartition(ModifyTableState *mtstate, if (proute->subplan_resultrel_htab) { Oid partoid = partdesc->oids[partidx]; - SubplanResultRelHashElem *elem; + SubplanResultRelHashElem *elem; elem = hash_search(proute->subplan_resultrel_htab, &partoid, HASH_FIND, NULL); @@ -474,7 +474,7 @@ ExecHashSubPlanResultRelsByOid(ModifyTableState *mtstate, ResultRelInfo *rri = &mtstate->resultRelInfo[i]; bool found; Oid partoid = RelationGetRelid(rri->ri_RelationDesc); - SubplanResultRelHashElem *elem; + SubplanResultRelHashElem *elem; elem = (SubplanResultRelHashElem *) hash_search(htab, &partoid, HASH_ENTER, &found); @@ -762,9 +762,9 @@ ExecInitPartitionInfo(ModifyTableState *mtstate, EState *estate, * It's safe to reuse these from the partition root, as we * only process one tuple at a time (therefore we won't * overwrite needed data in slots), and the results of - * projections are independent of the underlying - * storage. Projections and where clauses themselves don't - * store state / are independent of the underlying storage. + * projections are independent of the underlying storage. + * Projections and where clauses themselves don't store state + * / are independent of the underlying storage. */ leaf_part_rri->ri_onConflict->oc_ProjSlot = rootResultRelInfo->ri_onConflict->oc_ProjSlot; @@ -892,7 +892,7 @@ ExecInitRoutingInfo(ModifyTableState *mtstate, { MemoryContext oldcxt; PartitionRoutingInfo *partrouteinfo; - int rri_index; + int rri_index; oldcxt = MemoryContextSwitchTo(proute->memcxt); @@ -1668,16 +1668,16 @@ ExecCreatePartitionPruneState(PlanState *planstate, } else { - int pd_idx = 0; - int pp_idx; + int pd_idx = 0; + int pp_idx; /* * Some new partitions have appeared since plan time, and * those are reflected in our PartitionDesc but were not * present in the one used to construct subplan_map and * subpart_map. So we must construct new and longer arrays - * where the partitions that were originally present map to the - * same place, and any added indexes map to -1, as if the + * where the partitions that were originally present map to + * the same place, and any added indexes map to -1, as if the * new partitions had been pruned. */ pprune->subpart_map = palloc(sizeof(int) * partdesc->nparts); diff --git a/src/backend/executor/execReplication.c b/src/backend/executor/execReplication.c index f8f6463358f..0326284c83f 100644 --- a/src/backend/executor/execReplication.c +++ b/src/backend/executor/execReplication.c @@ -227,7 +227,7 @@ retry: static bool tuples_equal(TupleTableSlot *slot1, TupleTableSlot *slot2) { - int attrnum; + int attrnum; Assert(slot1->tts_tupleDescriptor->natts == slot2->tts_tupleDescriptor->natts); @@ -265,8 +265,8 @@ tuples_equal(TupleTableSlot *slot1, TupleTableSlot *slot2) if (!DatumGetBool(FunctionCall2Coll(&typentry->eq_opr_finfo, att->attcollation, - slot1->tts_values[attrnum], - slot2->tts_values[attrnum]))) + slot1->tts_values[attrnum], + slot2->tts_values[attrnum]))) return false; } @@ -406,7 +406,7 @@ ExecSimpleRelationInsert(EState *estate, TupleTableSlot *slot) resultRelInfo->ri_TrigDesc->trig_insert_before_row) { if (!ExecBRInsertTriggers(estate, resultRelInfo, slot)) - skip_tuple = true; /* "do nothing" */ + skip_tuple = true; /* "do nothing" */ } if (!skip_tuple) @@ -471,7 +471,7 @@ ExecSimpleRelationUpdate(EState *estate, EPQState *epqstate, { if (!ExecBRUpdateTriggers(estate, epqstate, resultRelInfo, tid, NULL, slot)) - skip_tuple = true; /* "do nothing" */ + skip_tuple = true; /* "do nothing" */ } if (!skip_tuple) @@ -490,7 +490,7 @@ ExecSimpleRelationUpdate(EState *estate, EPQState *epqstate, if (resultRelInfo->ri_PartitionCheck) ExecPartitionCheck(resultRelInfo, slot, estate, true); - simple_table_update(rel, tid, slot,estate->es_snapshot, + simple_table_update(rel, tid, slot, estate->es_snapshot, &update_indexes); if (resultRelInfo->ri_NumIndices > 0 && update_indexes) @@ -591,8 +591,8 @@ CheckSubscriptionRelkind(char relkind, const char *nspname, const char *relname) { /* - * We currently only support writing to regular tables. However, give - * a more specific error for partitioned and foreign tables. + * We currently only support writing to regular tables. However, give a + * more specific error for partitioned and foreign tables. */ if (relkind == RELKIND_PARTITIONED_TABLE) ereport(ERROR, @@ -600,14 +600,14 @@ CheckSubscriptionRelkind(char relkind, const char *nspname, errmsg("cannot use relation \"%s.%s\" as logical replication target", nspname, relname), errdetail("\"%s.%s\" is a partitioned table.", - nspname, relname))); + nspname, relname))); else if (relkind == RELKIND_FOREIGN_TABLE) ereport(ERROR, (errcode(ERRCODE_WRONG_OBJECT_TYPE), errmsg("cannot use relation \"%s.%s\" as logical replication target", nspname, relname), errdetail("\"%s.%s\" is a foreign table.", - nspname, relname))); + nspname, relname))); if (relkind != RELKIND_RELATION) ereport(ERROR, @@ -615,5 +615,5 @@ CheckSubscriptionRelkind(char relkind, const char *nspname, errmsg("cannot use relation \"%s.%s\" as logical replication target", nspname, relname), errdetail("\"%s.%s\" is not a table.", - nspname, relname))); + nspname, relname))); } diff --git a/src/backend/executor/execScan.c b/src/backend/executor/execScan.c index 881131aff26..67c4be5108f 100644 --- a/src/backend/executor/execScan.c +++ b/src/backend/executor/execScan.c @@ -81,7 +81,8 @@ ExecScanFetch(ScanState *node, /* Check if it meets the access-method conditions */ if (!(*recheckMtd) (node, slot)) - return ExecClearTuple(slot); /* would not be returned by scan */ + return ExecClearTuple(slot); /* would not be returned by + * scan */ return slot; } diff --git a/src/backend/executor/execTuples.c b/src/backend/executor/execTuples.c index 55d1669db09..ad13fd9a05b 100644 --- a/src/backend/executor/execTuples.c +++ b/src/backend/executor/execTuples.c @@ -71,13 +71,12 @@ static TupleDesc ExecTypeFromTLInternal(List *targetList, bool skipjunk); -static pg_attribute_always_inline void -slot_deform_heap_tuple(TupleTableSlot *slot, HeapTuple tuple, uint32 *offp, +static pg_attribute_always_inline void slot_deform_heap_tuple(TupleTableSlot *slot, HeapTuple tuple, uint32 *offp, int natts); static inline void tts_buffer_heap_store_tuple(TupleTableSlot *slot, - HeapTuple tuple, - Buffer buffer, - bool transfer_pin); + HeapTuple tuple, + Buffer buffer, + bool transfer_pin); static void tts_heap_store_tuple(TupleTableSlot *slot, HeapTuple tuple, bool shouldFree); @@ -138,7 +137,7 @@ tts_virtual_getsysattr(TupleTableSlot *slot, int attnum, bool *isnull) { elog(ERROR, "virtual tuple table slot does not have system attributes"); - return 0; /* silence compiler warnings */ + return 0; /* silence compiler warnings */ } /* @@ -164,7 +163,7 @@ tts_virtual_materialize(TupleTableSlot *slot) for (int natt = 0; natt < desc->natts; natt++) { Form_pg_attribute att = TupleDescAttr(desc, natt); - Datum val; + Datum val; if (att->attbyval || slot->tts_isnull[natt]) continue; @@ -200,7 +199,7 @@ tts_virtual_materialize(TupleTableSlot *slot) for (int natt = 0; natt < desc->natts; natt++) { Form_pg_attribute att = TupleDescAttr(desc, natt); - Datum val; + Datum val; if (att->attbyval || slot->tts_isnull[natt]) continue; @@ -210,7 +209,7 @@ tts_virtual_materialize(TupleTableSlot *slot) if (att->attlen == -1 && VARATT_IS_EXTERNAL_EXPANDED(DatumGetPointer(val))) { - Size data_length; + Size data_length; /* * We want to flatten the expanded value so that the materialized @@ -228,7 +227,7 @@ tts_virtual_materialize(TupleTableSlot *slot) } else { - Size data_length = 0; + Size data_length = 0; data = (char *) att_align_nominal(data, att->attalign); data_length = att_addlength_datum(data_length, att->attlen, val); @@ -382,7 +381,7 @@ tts_heap_materialize(TupleTableSlot *slot) static void tts_heap_copyslot(TupleTableSlot *dstslot, TupleTableSlot *srcslot) { - HeapTuple tuple; + HeapTuple tuple; MemoryContext oldcontext; oldcontext = MemoryContextSwitchTo(dstslot->tts_mcxt); @@ -499,7 +498,7 @@ tts_minimal_getsysattr(TupleTableSlot *slot, int attnum, bool *isnull) { elog(ERROR, "minimal tuple table slot does not have system attributes"); - return 0; /* silence compiler warnings */ + return 0; /* silence compiler warnings */ } static void @@ -1077,8 +1076,10 @@ TupleTableSlot * MakeTupleTableSlot(TupleDesc tupleDesc, const TupleTableSlotOps *tts_ops) { - Size basesz, allocsz; + Size basesz, + allocsz; TupleTableSlot *slot; + basesz = tts_ops->base_slot_size; /* @@ -1866,7 +1867,7 @@ void slot_getsomeattrs_int(TupleTableSlot *slot, int attnum) { /* Check for caller errors */ - Assert(slot->tts_nvalid < attnum); /* slot_getsomeattr checked */ + Assert(slot->tts_nvalid < attnum); /* slot_getsomeattr checked */ Assert(attnum > 0); if (unlikely(attnum > slot->tts_tupleDescriptor->natts)) @@ -1876,8 +1877,8 @@ slot_getsomeattrs_int(TupleTableSlot *slot, int attnum) slot->tts_ops->getsomeattrs(slot, attnum); /* - * If the underlying tuple doesn't have enough attributes, tuple descriptor - * must have the missing attributes. + * If the underlying tuple doesn't have enough attributes, tuple + * descriptor must have the missing attributes. */ if (unlikely(slot->tts_nvalid < attnum)) { diff --git a/src/backend/executor/functions.c b/src/backend/executor/functions.c index 965e5dea70e..b34f565bfe7 100644 --- a/src/backend/executor/functions.c +++ b/src/backend/executor/functions.c @@ -1762,7 +1762,7 @@ check_sql_fn_retval(Oid func_id, Oid rettype, List *queryTreeList, if (junkFilter) { TupleTableSlot *slot = - MakeSingleTupleTableSlot(NULL, &TTSOpsMinimalTuple); + MakeSingleTupleTableSlot(NULL, &TTSOpsMinimalTuple); *junkFilter = ExecInitJunkFilter(tlist, slot); } @@ -1929,7 +1929,7 @@ check_sql_fn_retval(Oid func_id, Oid rettype, List *queryTreeList, if (junkFilter) { TupleTableSlot *slot = - MakeSingleTupleTableSlot(NULL, &TTSOpsMinimalTuple); + MakeSingleTupleTableSlot(NULL, &TTSOpsMinimalTuple); *junkFilter = ExecInitJunkFilterConversion(tlist, CreateTupleDescCopy(tupdesc), diff --git a/src/backend/executor/nodeAgg.c b/src/backend/executor/nodeAgg.c index fd3c71e7641..43ab9fb3924 100644 --- a/src/backend/executor/nodeAgg.c +++ b/src/backend/executor/nodeAgg.c @@ -754,7 +754,7 @@ process_ordered_aggregate_single(AggState *aggstate, oldAbbrevVal == newAbbrevVal && DatumGetBool(FunctionCall2Coll(&pertrans->equalfnOne, pertrans->aggCollation, - oldVal, *newVal))))) + oldVal, *newVal))))) { /* equal to prior, so forget this one */ if (!pertrans->inputtypeByVal && !*isNull) diff --git a/src/backend/executor/nodeGatherMerge.c b/src/backend/executor/nodeGatherMerge.c index 4de1d2b484d..d2da5d3a951 100644 --- a/src/backend/executor/nodeGatherMerge.c +++ b/src/backend/executor/nodeGatherMerge.c @@ -700,10 +700,10 @@ gather_merge_readnext(GatherMergeState *gm_state, int reader, bool nowait) Assert(HeapTupleIsValid(tup)); /* Build the TupleTableSlot for the given tuple */ - ExecStoreHeapTuple(tup, /* tuple to store */ + ExecStoreHeapTuple(tup, /* tuple to store */ gm_state->gm_slots[reader], /* slot in which to store * the tuple */ - true); /* pfree tuple when done with it */ + true); /* pfree tuple when done with it */ return true; } diff --git a/src/backend/executor/nodeHashjoin.c b/src/backend/executor/nodeHashjoin.c index aa43296e26c..5ccdc1af2e8 100644 --- a/src/backend/executor/nodeHashjoin.c +++ b/src/backend/executor/nodeHashjoin.c @@ -750,7 +750,7 @@ ExecInitHashJoin(HashJoin *node, EState *estate, int eflags) rclauses = lappend(rclauses, ExecInitExpr(lsecond(hclause->args), (PlanState *) hjstate)); rhclauses = lappend(rhclauses, ExecInitExpr(lsecond(hclause->args), - innerPlanState(hjstate))); + innerPlanState(hjstate))); hoperators = lappend_oid(hoperators, hclause->opno); hcollations = lappend_oid(hcollations, hclause->inputcollid); } diff --git a/src/backend/executor/nodeIndexonlyscan.c b/src/backend/executor/nodeIndexonlyscan.c index 8fd52e9c803..5dce284fe73 100644 --- a/src/backend/executor/nodeIndexonlyscan.c +++ b/src/backend/executor/nodeIndexonlyscan.c @@ -192,9 +192,9 @@ IndexOnlyNext(IndexOnlyScanState *node) /* * Fill the scan tuple slot with data from the index. This might be - * provided in either HeapTuple or IndexTuple format. Conceivably - * an index AM might fill both fields, in which case we prefer the - * heap format, since it's probably a bit cheaper to fill a slot from. + * provided in either HeapTuple or IndexTuple format. Conceivably an + * index AM might fill both fields, in which case we prefer the heap + * format, since it's probably a bit cheaper to fill a slot from. */ if (scandesc->xs_hitup) { diff --git a/src/backend/executor/nodeIndexscan.c b/src/backend/executor/nodeIndexscan.c index c97eb60f779..73bfd424d98 100644 --- a/src/backend/executor/nodeIndexscan.c +++ b/src/backend/executor/nodeIndexscan.c @@ -242,7 +242,7 @@ IndexNextWithReorder(IndexScanState *node) scandesc->xs_orderbynulls, node) <= 0) { - HeapTuple tuple; + HeapTuple tuple; tuple = reorderqueue_pop(node); diff --git a/src/backend/executor/nodeLockRows.c b/src/backend/executor/nodeLockRows.c index 7674ac893c2..4067554ed94 100644 --- a/src/backend/executor/nodeLockRows.c +++ b/src/backend/executor/nodeLockRows.c @@ -327,7 +327,7 @@ ExecInitLockRows(LockRows *node, EState *estate, int eflags) /* node returns unmodified slots from the outer plan */ lrstate->ps.resultopsset = true; lrstate->ps.resultops = ExecGetResultSlotOps(outerPlanState(lrstate), - &lrstate->ps.resultopsfixed); + &lrstate->ps.resultopsfixed); /* * LockRows nodes do no projections, so initialize projection info for diff --git a/src/backend/executor/nodeModifyTable.c b/src/backend/executor/nodeModifyTable.c index d3a0dece5ad..8acdaf20573 100644 --- a/src/backend/executor/nodeModifyTable.c +++ b/src/backend/executor/nodeModifyTable.c @@ -865,6 +865,7 @@ ldelete:; goto ldelete; case TM_SelfModified: + /* * This can be reached when following an update * chain from a tuple updated by another session, @@ -1070,7 +1071,7 @@ ExecUpdate(ModifyTableState *mtstate, { if (!ExecBRUpdateTriggers(estate, epqstate, resultRelInfo, tupleid, oldtuple, slot)) - return NULL; /* "do nothing" */ + return NULL; /* "do nothing" */ } /* INSTEAD OF ROW UPDATE Triggers */ @@ -1079,7 +1080,7 @@ ExecUpdate(ModifyTableState *mtstate, { if (!ExecIRUpdateTriggers(estate, resultRelInfo, oldtuple, slot)) - return NULL; /* "do nothing" */ + return NULL; /* "do nothing" */ } else if (resultRelInfo->ri_FdwRoutine) { @@ -1401,6 +1402,7 @@ lreplace:; return NULL; case TM_SelfModified: + /* * This can be reached when following an update * chain from a tuple updated by another session, diff --git a/src/backend/executor/nodeSeqscan.c b/src/backend/executor/nodeSeqscan.c index 8bd7430a918..436b43f8ca5 100644 --- a/src/backend/executor/nodeSeqscan.c +++ b/src/backend/executor/nodeSeqscan.c @@ -228,8 +228,8 @@ ExecReScanSeqScan(SeqScanState *node) scan = node->ss.ss_currentScanDesc; if (scan != NULL) - table_rescan(scan, /* scan desc */ - NULL); /* new scan keys */ + table_rescan(scan, /* scan desc */ + NULL); /* new scan keys */ ExecScanReScan((ScanState *) node); } diff --git a/src/backend/executor/nodeSubplan.c b/src/backend/executor/nodeSubplan.c index 749b4eced34..3662fcada8c 100644 --- a/src/backend/executor/nodeSubplan.c +++ b/src/backend/executor/nodeSubplan.c @@ -684,7 +684,7 @@ execTuplesUnequal(TupleTableSlot *slot1, /* Apply the type-specific equality function */ if (!DatumGetBool(FunctionCall2Coll(&eqfunctions[i], collations[i], - attr1, attr2))) + attr1, attr2))) { result = true; /* they are unequal */ break; diff --git a/src/backend/executor/nodeSubqueryscan.c b/src/backend/executor/nodeSubqueryscan.c index 707ec0d1901..de8c0060510 100644 --- a/src/backend/executor/nodeSubqueryscan.c +++ b/src/backend/executor/nodeSubqueryscan.c @@ -131,6 +131,7 @@ ExecInitSubqueryScan(SubqueryScan *node, EState *estate, int eflags) ExecInitScanTupleSlot(estate, &subquerystate->ss, ExecGetResultType(subquerystate->subplan), ExecGetResultSlotOps(subquerystate->subplan, NULL)); + /* * The slot used as the scantuple isn't the slot above (outside of EPQ), * but the one from the node below. |