#include "nodes/execnodes.h"
Go to the source code of this file.
void ExecChooseHashTableSize | ( | double | ntuples, | |
int | tupwidth, | |||
bool | useskew, | |||
int * | numbuckets, | |||
int * | numbatches, | |||
int * | num_skew_mcvs | |||
) |
Definition at line 390 of file nodeHash.c.
References HJTUPLE_OVERHEAD, i, MAXALIGN, Min, NTUP_PER_BUCKET, SKEW_BUCKET_OVERHEAD, SKEW_WORK_MEM_PERCENT, and work_mem.
Referenced by ExecHashTableCreate(), and initial_cost_hashjoin().
{ int tupsize; double inner_rel_bytes; long hash_table_bytes; long skew_table_bytes; long max_pointers; int nbatch; int nbuckets; int i; /* Force a plausible relation size if no info */ if (ntuples <= 0.0) ntuples = 1000.0; /* * Estimate tupsize based on footprint of tuple in hashtable... note this * does not allow for any palloc overhead. The manipulations of spaceUsed * don't count palloc overhead either. */ tupsize = HJTUPLE_OVERHEAD + MAXALIGN(sizeof(MinimalTupleData)) + MAXALIGN(tupwidth); inner_rel_bytes = ntuples * tupsize; /* * Target in-memory hashtable size is work_mem kilobytes. */ hash_table_bytes = work_mem * 1024L; /* * If skew optimization is possible, estimate the number of skew buckets * that will fit in the memory allowed, and decrement the assumed space * available for the main hash table accordingly. * * We make the optimistic assumption that each skew bucket will contain * one inner-relation tuple. If that turns out to be low, we will recover * at runtime by reducing the number of skew buckets. * * hashtable->skewBucket will have up to 8 times as many HashSkewBucket * pointers as the number of MCVs we allow, since ExecHashBuildSkewHash * will round up to the next power of 2 and then multiply by 4 to reduce * collisions. */ if (useskew) { skew_table_bytes = hash_table_bytes * SKEW_WORK_MEM_PERCENT / 100; /*---------- * Divisor is: * size of a hash tuple + * worst-case size of skewBucket[] per MCV + * size of skewBucketNums[] entry + * size of skew bucket struct itself *---------- */ *num_skew_mcvs = skew_table_bytes / (tupsize + (8 * sizeof(HashSkewBucket *)) + sizeof(int) + SKEW_BUCKET_OVERHEAD); if (*num_skew_mcvs > 0) hash_table_bytes -= skew_table_bytes; } else *num_skew_mcvs = 0; /* * Set nbuckets to achieve an average bucket load of NTUP_PER_BUCKET when * memory is filled. Set nbatch to the smallest power of 2 that appears * sufficient. The Min() steps limit the results so that the pointer * arrays we'll try to allocate do not exceed work_mem. */ max_pointers = (work_mem * 1024L) / sizeof(void *); /* also ensure we avoid integer overflow in nbatch and nbuckets */ max_pointers = Min(max_pointers, INT_MAX / 2); if (inner_rel_bytes > hash_table_bytes) { /* We'll need multiple batches */ long lbuckets; double dbatch; int minbatch; lbuckets = (hash_table_bytes / tupsize) / NTUP_PER_BUCKET; lbuckets = Min(lbuckets, max_pointers); nbuckets = (int) lbuckets; dbatch = ceil(inner_rel_bytes / hash_table_bytes); dbatch = Min(dbatch, max_pointers); minbatch = (int) dbatch; nbatch = 2; while (nbatch < minbatch) nbatch <<= 1; } else { /* We expect the hashtable to fit in memory */ double dbuckets; dbuckets = ceil(ntuples / NTUP_PER_BUCKET); dbuckets = Min(dbuckets, max_pointers); nbuckets = (int) dbuckets; nbatch = 1; } /* * Both nbuckets and nbatch must be powers of 2 to make * ExecHashGetBucketAndBatch fast. We already fixed nbatch; now inflate * nbuckets to the next larger power of 2. We also force nbuckets to not * be real small, by starting the search at 2^10. (Note: above we made * sure that nbuckets is not more than INT_MAX / 2, so this loop cannot * overflow, nor can the final shift to recalculate nbuckets.) */ i = 10; while ((1 << i) < nbuckets) i++; nbuckets = (1 << i); *numbuckets = nbuckets; *numbatches = nbatch; }
void ExecEndHash | ( | HashState * | node | ) |
Definition at line 210 of file nodeHash.c.
References ExecEndNode(), ExecFreeExprContext(), outerPlanState, and HashState::ps.
Referenced by ExecEndNode().
{ PlanState *outerPlan; /* * free exprcontext */ ExecFreeExprContext(&node->ps); /* * shut down the subplan */ outerPlan = outerPlanState(node); ExecEndNode(outerPlan); }
TupleTableSlot* ExecHash | ( | HashState * | node | ) |
Definition at line 58 of file nodeHash.c.
Referenced by ExecProcNode().
void ExecHashGetBucketAndBatch | ( | HashJoinTable | hashtable, | |
uint32 | hashvalue, | |||
int * | bucketno, | |||
int * | batchno | |||
) |
Definition at line 871 of file nodeHash.c.
References HashJoinTableData::log2_nbuckets, HashJoinTableData::nbatch, and HashJoinTableData::nbuckets.
Referenced by ExecHashIncreaseNumBatches(), ExecHashJoin(), ExecHashRemoveNextSkewBucket(), and ExecHashTableInsert().
{ uint32 nbuckets = (uint32) hashtable->nbuckets; uint32 nbatch = (uint32) hashtable->nbatch; if (nbatch > 1) { /* we can do MOD by masking, DIV by shifting */ *bucketno = hashvalue & (nbuckets - 1); *batchno = (hashvalue >> hashtable->log2_nbuckets) & (nbatch - 1); } else { *bucketno = hashvalue & (nbuckets - 1); *batchno = 0; } }
bool ExecHashGetHashValue | ( | HashJoinTable | hashtable, | |
ExprContext * | econtext, | |||
List * | hashkeys, | |||
bool | outer_tuple, | |||
bool | keep_nulls, | |||
uint32 * | hashvalue | |||
) |
Definition at line 770 of file nodeHash.c.
References DatumGetUInt32, ExprContext::ecxt_per_tuple_memory, ExecEvalExpr, FunctionCall1, HashJoinTableData::hashStrict, i, HashJoinTableData::inner_hashfunctions, lfirst, MemoryContextSwitchTo(), NULL, HashJoinTableData::outer_hashfunctions, and ResetExprContext.
Referenced by ExecHashJoinOuterGetTuple(), and MultiExecHash().
{ uint32 hashkey = 0; FmgrInfo *hashfunctions; ListCell *hk; int i = 0; MemoryContext oldContext; /* * We reset the eval context each time to reclaim any memory leaked in the * hashkey expressions. */ ResetExprContext(econtext); oldContext = MemoryContextSwitchTo(econtext->ecxt_per_tuple_memory); if (outer_tuple) hashfunctions = hashtable->outer_hashfunctions; else hashfunctions = hashtable->inner_hashfunctions; foreach(hk, hashkeys) { ExprState *keyexpr = (ExprState *) lfirst(hk); Datum keyval; bool isNull; /* rotate hashkey left 1 bit at each step */ hashkey = (hashkey << 1) | ((hashkey & 0x80000000) ? 1 : 0); /* * Get the join attribute value of the tuple */ keyval = ExecEvalExpr(keyexpr, econtext, &isNull, NULL); /* * If the attribute is NULL, and the join operator is strict, then * this tuple cannot pass the join qual so we can reject it * immediately (unless we're scanning the outside of an outer join, in * which case we must not reject it). Otherwise we act like the * hashcode of NULL is zero (this will support operators that act like * IS NOT DISTINCT, though not any more-random behavior). We treat * the hash support function as strict even if the operator is not. * * Note: currently, all hashjoinable operators must be strict since * the hash index AM assumes that. However, it takes so little extra * code here to allow non-strict that we may as well do it. */ if (isNull) { if (hashtable->hashStrict[i] && !keep_nulls) { MemoryContextSwitchTo(oldContext); return false; /* cannot match */ } /* else, leave hashkey unmodified, equivalent to hashcode 0 */ } else { /* Compute the hash function */ uint32 hkey; hkey = DatumGetUInt32(FunctionCall1(&hashfunctions[i], keyval)); hashkey ^= hkey; } i++; } MemoryContextSwitchTo(oldContext); *hashvalue = hashkey; return true; }
int ExecHashGetSkewBucket | ( | HashJoinTable | hashtable, | |
uint32 | hashvalue | |||
) |
Definition at line 1284 of file nodeHash.c.
References HashSkewBucket::hashvalue, NULL, HashJoinTableData::skewBucket, HashJoinTableData::skewBucketLen, and HashJoinTableData::skewEnabled.
Referenced by ExecHashJoin(), and MultiExecHash().
{ int bucket; /* * Always return INVALID_SKEW_BUCKET_NO if not doing skew optimization (in * particular, this happens after the initial batch is done). */ if (!hashtable->skewEnabled) return INVALID_SKEW_BUCKET_NO; /* * Since skewBucketLen is a power of 2, we can do a modulo by ANDing. */ bucket = hashvalue & (hashtable->skewBucketLen - 1); /* * While we have not hit a hole in the hashtable and have not hit the * desired bucket, we have collided with some other hash value, so try the * next bucket location. */ while (hashtable->skewBucket[bucket] != NULL && hashtable->skewBucket[bucket]->hashvalue != hashvalue) bucket = (bucket + 1) & (hashtable->skewBucketLen - 1); /* * Found the desired bucket? */ if (hashtable->skewBucket[bucket] != NULL) return bucket; /* * There must not be any hashtable entry for this hash value. */ return INVALID_SKEW_BUCKET_NO; }
HashJoinTable ExecHashTableCreate | ( | Hash * | node, | |
List * | hashOperators, | |||
bool | keepNulls | |||
) |
Definition at line 234 of file nodeHash.c.
References ALLOCSET_DEFAULT_INITSIZE, ALLOCSET_DEFAULT_MAXSIZE, ALLOCSET_DEFAULT_MINSIZE, AllocSetContextCreate(), Assert, HashJoinTableData::batchCxt, HashJoinTableData::buckets, HashJoinTableData::curbatch, CurrentMemoryContext, elog, ERROR, ExecChooseHashTableSize(), ExecHashBuildSkewHash(), fmgr_info(), get_op_hash_functions(), HashJoinTableData::growEnabled, HashJoinTableData::hashCxt, HashJoinTableData::hashStrict, i, HashJoinTableData::inner_hashfunctions, HashJoinTableData::innerBatchFile, HashJoinTableData::keepNulls, lfirst_oid, list_length(), HashJoinTableData::log2_nbuckets, MemoryContextSwitchTo(), my_log2(), HashJoinTableData::nbatch, HashJoinTableData::nbatch_original, HashJoinTableData::nbatch_outstart, HashJoinTableData::nbuckets, HashJoinTableData::nSkewBuckets, OidIsValid, op_strict(), HashJoinTableData::outer_hashfunctions, HashJoinTableData::outerBatchFile, outerPlan, palloc(), palloc0(), Plan::plan_rows, Plan::plan_width, PrepareTempTablespaces(), SKEW_WORK_MEM_PERCENT, HashJoinTableData::skewBucket, HashJoinTableData::skewBucketLen, HashJoinTableData::skewBucketNums, HashJoinTableData::skewEnabled, Hash::skewTable, HashJoinTableData::spaceAllowed, HashJoinTableData::spaceAllowedSkew, HashJoinTableData::spacePeak, HashJoinTableData::spaceUsed, HashJoinTableData::spaceUsedSkew, HashJoinTableData::totalTuples, and work_mem.
Referenced by ExecHashJoin().
{ HashJoinTable hashtable; Plan *outerNode; int nbuckets; int nbatch; int num_skew_mcvs; int log2_nbuckets; int nkeys; int i; ListCell *ho; MemoryContext oldcxt; /* * Get information about the size of the relation to be hashed (it's the * "outer" subtree of this node, but the inner relation of the hashjoin). * Compute the appropriate size of the hash table. */ outerNode = outerPlan(node); ExecChooseHashTableSize(outerNode->plan_rows, outerNode->plan_width, OidIsValid(node->skewTable), &nbuckets, &nbatch, &num_skew_mcvs); #ifdef HJDEBUG printf("nbatch = %d, nbuckets = %d\n", nbatch, nbuckets); #endif /* nbuckets must be a power of 2 */ log2_nbuckets = my_log2(nbuckets); Assert(nbuckets == (1 << log2_nbuckets)); /* * Initialize the hash table control block. * * The hashtable control block is just palloc'd from the executor's * per-query memory context. */ hashtable = (HashJoinTable) palloc(sizeof(HashJoinTableData)); hashtable->nbuckets = nbuckets; hashtable->log2_nbuckets = log2_nbuckets; hashtable->buckets = NULL; hashtable->keepNulls = keepNulls; hashtable->skewEnabled = false; hashtable->skewBucket = NULL; hashtable->skewBucketLen = 0; hashtable->nSkewBuckets = 0; hashtable->skewBucketNums = NULL; hashtable->nbatch = nbatch; hashtable->curbatch = 0; hashtable->nbatch_original = nbatch; hashtable->nbatch_outstart = nbatch; hashtable->growEnabled = true; hashtable->totalTuples = 0; hashtable->innerBatchFile = NULL; hashtable->outerBatchFile = NULL; hashtable->spaceUsed = 0; hashtable->spacePeak = 0; hashtable->spaceAllowed = work_mem * 1024L; hashtable->spaceUsedSkew = 0; hashtable->spaceAllowedSkew = hashtable->spaceAllowed * SKEW_WORK_MEM_PERCENT / 100; /* * Get info about the hash functions to be used for each hash key. Also * remember whether the join operators are strict. */ nkeys = list_length(hashOperators); hashtable->outer_hashfunctions = (FmgrInfo *) palloc(nkeys * sizeof(FmgrInfo)); hashtable->inner_hashfunctions = (FmgrInfo *) palloc(nkeys * sizeof(FmgrInfo)); hashtable->hashStrict = (bool *) palloc(nkeys * sizeof(bool)); i = 0; foreach(ho, hashOperators) { Oid hashop = lfirst_oid(ho); Oid left_hashfn; Oid right_hashfn; if (!get_op_hash_functions(hashop, &left_hashfn, &right_hashfn)) elog(ERROR, "could not find hash function for hash operator %u", hashop); fmgr_info(left_hashfn, &hashtable->outer_hashfunctions[i]); fmgr_info(right_hashfn, &hashtable->inner_hashfunctions[i]); hashtable->hashStrict[i] = op_strict(hashop); i++; } /* * Create temporary memory contexts in which to keep the hashtable working * storage. See notes in executor/hashjoin.h. */ hashtable->hashCxt = AllocSetContextCreate(CurrentMemoryContext, "HashTableContext", ALLOCSET_DEFAULT_MINSIZE, ALLOCSET_DEFAULT_INITSIZE, ALLOCSET_DEFAULT_MAXSIZE); hashtable->batchCxt = AllocSetContextCreate(hashtable->hashCxt, "HashBatchContext", ALLOCSET_DEFAULT_MINSIZE, ALLOCSET_DEFAULT_INITSIZE, ALLOCSET_DEFAULT_MAXSIZE); /* Allocate data that will live for the life of the hashjoin */ oldcxt = MemoryContextSwitchTo(hashtable->hashCxt); if (nbatch > 1) { /* * allocate and initialize the file arrays in hashCxt */ hashtable->innerBatchFile = (BufFile **) palloc0(nbatch * sizeof(BufFile *)); hashtable->outerBatchFile = (BufFile **) palloc0(nbatch * sizeof(BufFile *)); /* The files will not be opened until needed... */ /* ... but make sure we have temp tablespaces established for them */ PrepareTempTablespaces(); } /* * Prepare context for the first-scan space allocations; allocate the * hashbucket array therein, and set each bucket "empty". */ MemoryContextSwitchTo(hashtable->batchCxt); hashtable->buckets = (HashJoinTuple *) palloc0(nbuckets * sizeof(HashJoinTuple)); /* * Set up for skew optimization, if possible and there's a need for more * than one batch. (In a one-batch join, there's no point in it.) */ if (nbatch > 1) ExecHashBuildSkewHash(hashtable, node, num_skew_mcvs); MemoryContextSwitchTo(oldcxt); return hashtable; }
void ExecHashTableDestroy | ( | HashJoinTable | hashtable | ) |
Definition at line 524 of file nodeHash.c.
References BufFileClose(), HashJoinTableData::hashCxt, i, HashJoinTableData::innerBatchFile, MemoryContextDelete(), HashJoinTableData::nbatch, HashJoinTableData::outerBatchFile, and pfree().
Referenced by ExecEndHashJoin(), and ExecReScanHashJoin().
{ int i; /* * Make sure all the temp files are closed. We skip batch 0, since it * can't have any temp files (and the arrays might not even exist if * nbatch is only 1). */ for (i = 1; i < hashtable->nbatch; i++) { if (hashtable->innerBatchFile[i]) BufFileClose(hashtable->innerBatchFile[i]); if (hashtable->outerBatchFile[i]) BufFileClose(hashtable->outerBatchFile[i]); } /* Release working memory (batchCxt is a child, so it goes away too) */ MemoryContextDelete(hashtable->hashCxt); /* And drop the control block */ pfree(hashtable); }
void ExecHashTableInsert | ( | HashJoinTable | hashtable, | |
TupleTableSlot * | slot, | |||
uint32 | hashvalue | |||
) |
Definition at line 696 of file nodeHash.c.
References Assert, HashJoinTableData::batchCxt, HashJoinTableData::buckets, HashJoinTableData::curbatch, ExecFetchSlotMinimalTuple(), ExecHashGetBucketAndBatch(), ExecHashIncreaseNumBatches(), ExecHashJoinSaveTuple(), HashJoinTupleData::hashvalue, HeapTupleHeaderClearMatch, HJTUPLE_MINTUPLE, HJTUPLE_OVERHEAD, HashJoinTableData::innerBatchFile, MemoryContextAlloc(), HashJoinTupleData::next, HashJoinTableData::spaceAllowed, HashJoinTableData::spacePeak, HashJoinTableData::spaceUsed, and MinimalTupleData::t_len.
Referenced by ExecHashJoinNewBatch(), and MultiExecHash().
{ MinimalTuple tuple = ExecFetchSlotMinimalTuple(slot); int bucketno; int batchno; ExecHashGetBucketAndBatch(hashtable, hashvalue, &bucketno, &batchno); /* * decide whether to put the tuple in the hash table or a temp file */ if (batchno == hashtable->curbatch) { /* * put the tuple in hash table */ HashJoinTuple hashTuple; int hashTupleSize; /* Create the HashJoinTuple */ hashTupleSize = HJTUPLE_OVERHEAD + tuple->t_len; hashTuple = (HashJoinTuple) MemoryContextAlloc(hashtable->batchCxt, hashTupleSize); hashTuple->hashvalue = hashvalue; memcpy(HJTUPLE_MINTUPLE(hashTuple), tuple, tuple->t_len); /* * We always reset the tuple-matched flag on insertion. This is okay * even when reloading a tuple from a batch file, since the tuple * could not possibly have been matched to an outer tuple before it * went into the batch file. */ HeapTupleHeaderClearMatch(HJTUPLE_MINTUPLE(hashTuple)); /* Push it onto the front of the bucket's list */ hashTuple->next = hashtable->buckets[bucketno]; hashtable->buckets[bucketno] = hashTuple; /* Account for space used, and back off if we've used too much */ hashtable->spaceUsed += hashTupleSize; if (hashtable->spaceUsed > hashtable->spacePeak) hashtable->spacePeak = hashtable->spaceUsed; if (hashtable->spaceUsed > hashtable->spaceAllowed) ExecHashIncreaseNumBatches(hashtable); } else { /* * put the tuple into a temp file for later batches */ Assert(batchno > hashtable->curbatch); ExecHashJoinSaveTuple(tuple, hashvalue, &hashtable->innerBatchFile[batchno]); } }
void ExecHashTableReset | ( | HashJoinTable | hashtable | ) |
Definition at line 1052 of file nodeHash.c.
References HashJoinTableData::batchCxt, HashJoinTableData::buckets, MemoryContextReset(), MemoryContextSwitchTo(), HashJoinTableData::nbuckets, palloc0(), and HashJoinTableData::spaceUsed.
Referenced by ExecHashJoinNewBatch().
{ MemoryContext oldcxt; int nbuckets = hashtable->nbuckets; /* * Release all the hash buckets and tuples acquired in the prior pass, and * reinitialize the context for a new pass. */ MemoryContextReset(hashtable->batchCxt); oldcxt = MemoryContextSwitchTo(hashtable->batchCxt); /* Reallocate and reinitialize the hash bucket headers. */ hashtable->buckets = (HashJoinTuple *) palloc0(nbuckets * sizeof(HashJoinTuple)); hashtable->spaceUsed = 0; MemoryContextSwitchTo(oldcxt); }
void ExecHashTableResetMatchFlags | ( | HashJoinTable | hashtable | ) |
Definition at line 1078 of file nodeHash.c.
References HashJoinTableData::buckets, HeapTupleHeaderClearMatch, HJTUPLE_MINTUPLE, i, HashJoinTableData::nbuckets, HashJoinTupleData::next, HashJoinTableData::nSkewBuckets, NULL, HashJoinTableData::skewBucket, HashJoinTableData::skewBucketNums, and HashSkewBucket::tuples.
Referenced by ExecReScanHashJoin().
{ HashJoinTuple tuple; int i; /* Reset all flags in the main table ... */ for (i = 0; i < hashtable->nbuckets; i++) { for (tuple = hashtable->buckets[i]; tuple != NULL; tuple = tuple->next) HeapTupleHeaderClearMatch(HJTUPLE_MINTUPLE(tuple)); } /* ... and the same for the skew buckets, if any */ for (i = 0; i < hashtable->nSkewBuckets; i++) { int j = hashtable->skewBucketNums[i]; HashSkewBucket *skewBucket = hashtable->skewBucket[j]; for (tuple = skewBucket->tuples; tuple != NULL; tuple = tuple->next) HeapTupleHeaderClearMatch(HJTUPLE_MINTUPLE(tuple)); } }
Definition at line 150 of file nodeHash.c.
References Assert, EXEC_FLAG_BACKWARD, EXEC_FLAG_MARK, ExecAssignExprContext(), ExecAssignResultTypeFromTL(), ExecInitExpr(), ExecInitNode(), ExecInitResultTupleSlot(), HashState::hashkeys, HashState::hashtable, makeNode, outerPlan, outerPlanState, Hash::plan, PlanState::plan, HashState::ps, PlanState::ps_ProjInfo, Plan::qual, PlanState::qual, PlanState::state, Plan::targetlist, and PlanState::targetlist.
Referenced by ExecInitNode().
{ HashState *hashstate; /* check for unsupported flags */ Assert(!(eflags & (EXEC_FLAG_BACKWARD | EXEC_FLAG_MARK))); /* * create state structure */ hashstate = makeNode(HashState); hashstate->ps.plan = (Plan *) node; hashstate->ps.state = estate; hashstate->hashtable = NULL; hashstate->hashkeys = NIL; /* will be set by parent HashJoin */ /* * Miscellaneous initialization * * create expression context for node */ ExecAssignExprContext(estate, &hashstate->ps); /* * initialize our result slot */ ExecInitResultTupleSlot(estate, &hashstate->ps); /* * initialize child expressions */ hashstate->ps.targetlist = (List *) ExecInitExpr((Expr *) node->plan.targetlist, (PlanState *) hashstate); hashstate->ps.qual = (List *) ExecInitExpr((Expr *) node->plan.qual, (PlanState *) hashstate); /* * initialize child nodes */ outerPlanState(hashstate) = ExecInitNode(outerPlan(node), estate, eflags); /* * initialize tuple type. no need to initialize projection info because * this node doesn't do projections */ ExecAssignResultTypeFromTL(&hashstate->ps); hashstate->ps.ps_ProjInfo = NULL; return hashstate; }
void ExecPrepHashTableForUnmatched | ( | HashJoinState * | hjstate | ) |
Definition at line 961 of file nodeHash.c.
References HashJoinState::hj_CurBucketNo, HashJoinState::hj_CurSkewBucketNo, and HashJoinState::hj_CurTuple.
Referenced by ExecHashJoin().
{ /* * ---------- During this scan we use the HashJoinState fields as follows: * * hj_CurBucketNo: next regular bucket to scan hj_CurSkewBucketNo: next * skew bucket (an index into skewBucketNums) hj_CurTuple: last tuple * returned, or NULL to start next bucket ---------- */ hjstate->hj_CurBucketNo = 0; hjstate->hj_CurSkewBucketNo = 0; hjstate->hj_CurTuple = NULL; }
void ExecReScanHash | ( | HashState * | node | ) |
Definition at line 1103 of file nodeHash.c.
References PlanState::chgParam, ExecReScan(), PlanState::lefttree, NULL, and HashState::ps.
Referenced by ExecReScan().
bool ExecScanHashBucket | ( | HashJoinState * | hjstate, | |
ExprContext * | econtext | |||
) |
Definition at line 903 of file nodeHash.c.
References HashJoinTableData::buckets, ExprContext::ecxt_innertuple, ExecQual(), ExecStoreMinimalTuple(), HashJoinState::hashclauses, HashJoinTupleData::hashvalue, HashJoinState::hj_CurBucketNo, HashJoinState::hj_CurHashValue, HashJoinState::hj_CurSkewBucketNo, HashJoinState::hj_CurTuple, HashJoinState::hj_HashTable, HashJoinState::hj_HashTupleSlot, HJTUPLE_MINTUPLE, INVALID_SKEW_BUCKET_NO, HashJoinTupleData::next, NULL, ResetExprContext, HashJoinTableData::skewBucket, and HashSkewBucket::tuples.
Referenced by ExecHashJoin().
{ List *hjclauses = hjstate->hashclauses; HashJoinTable hashtable = hjstate->hj_HashTable; HashJoinTuple hashTuple = hjstate->hj_CurTuple; uint32 hashvalue = hjstate->hj_CurHashValue; /* * hj_CurTuple is the address of the tuple last returned from the current * bucket, or NULL if it's time to start scanning a new bucket. * * If the tuple hashed to a skew bucket then scan the skew bucket * otherwise scan the standard hashtable bucket. */ if (hashTuple != NULL) hashTuple = hashTuple->next; else if (hjstate->hj_CurSkewBucketNo != INVALID_SKEW_BUCKET_NO) hashTuple = hashtable->skewBucket[hjstate->hj_CurSkewBucketNo]->tuples; else hashTuple = hashtable->buckets[hjstate->hj_CurBucketNo]; while (hashTuple != NULL) { if (hashTuple->hashvalue == hashvalue) { TupleTableSlot *inntuple; /* insert hashtable's tuple into exec slot so ExecQual sees it */ inntuple = ExecStoreMinimalTuple(HJTUPLE_MINTUPLE(hashTuple), hjstate->hj_HashTupleSlot, false); /* do not pfree */ econtext->ecxt_innertuple = inntuple; /* reset temp memory each time to avoid leaks from qual expr */ ResetExprContext(econtext); if (ExecQual(hjclauses, econtext, false)) { hjstate->hj_CurTuple = hashTuple; return true; } } hashTuple = hashTuple->next; } /* * no match */ return false; }
bool ExecScanHashTableForUnmatched | ( | HashJoinState * | hjstate, | |
ExprContext * | econtext | |||
) |
Definition at line 984 of file nodeHash.c.
References HashJoinTableData::buckets, ExprContext::ecxt_innertuple, ExecStoreMinimalTuple(), HeapTupleHeaderHasMatch, HashJoinState::hj_CurBucketNo, HashJoinState::hj_CurSkewBucketNo, HashJoinState::hj_CurTuple, HashJoinState::hj_HashTable, HashJoinState::hj_HashTupleSlot, HJTUPLE_MINTUPLE, HashJoinTableData::nbuckets, HashJoinTupleData::next, HashJoinTableData::nSkewBuckets, NULL, ResetExprContext, HashJoinTableData::skewBucket, HashJoinTableData::skewBucketNums, and HashSkewBucket::tuples.
Referenced by ExecHashJoin().
{ HashJoinTable hashtable = hjstate->hj_HashTable; HashJoinTuple hashTuple = hjstate->hj_CurTuple; for (;;) { /* * hj_CurTuple is the address of the tuple last returned from the * current bucket, or NULL if it's time to start scanning a new * bucket. */ if (hashTuple != NULL) hashTuple = hashTuple->next; else if (hjstate->hj_CurBucketNo < hashtable->nbuckets) { hashTuple = hashtable->buckets[hjstate->hj_CurBucketNo]; hjstate->hj_CurBucketNo++; } else if (hjstate->hj_CurSkewBucketNo < hashtable->nSkewBuckets) { int j = hashtable->skewBucketNums[hjstate->hj_CurSkewBucketNo]; hashTuple = hashtable->skewBucket[j]->tuples; hjstate->hj_CurSkewBucketNo++; } else break; /* finished all buckets */ while (hashTuple != NULL) { if (!HeapTupleHeaderHasMatch(HJTUPLE_MINTUPLE(hashTuple))) { TupleTableSlot *inntuple; /* insert hashtable's tuple into exec slot */ inntuple = ExecStoreMinimalTuple(HJTUPLE_MINTUPLE(hashTuple), hjstate->hj_HashTupleSlot, false); /* do not pfree */ econtext->ecxt_innertuple = inntuple; /* * Reset temp memory each time; although this function doesn't * do any qual eval, the caller will, so let's keep it * parallel to ExecScanHashBucket. */ ResetExprContext(econtext); hjstate->hj_CurTuple = hashTuple; return true; } hashTuple = hashTuple->next; } } /* * no more unmatched tuples */ return false; }
Definition at line 72 of file nodeHash.c.
References ExprContext::ecxt_innertuple, ExecHashGetHashValue(), ExecHashGetSkewBucket(), ExecHashSkewTableInsert(), ExecHashTableInsert(), ExecProcNode(), HashState::hashkeys, HashState::hashtable, InstrStartNode(), InstrStopNode(), PlanState::instrument, INVALID_SKEW_BUCKET_NO, HashJoinTableData::keepNulls, outerPlanState, HashState::ps, PlanState::ps_ExprContext, HashJoinTableData::totalTuples, and TupIsNull.
Referenced by MultiExecProcNode().
{ PlanState *outerNode; List *hashkeys; HashJoinTable hashtable; TupleTableSlot *slot; ExprContext *econtext; uint32 hashvalue; /* must provide our own instrumentation support */ if (node->ps.instrument) InstrStartNode(node->ps.instrument); /* * get state info from node */ outerNode = outerPlanState(node); hashtable = node->hashtable; /* * set expression context */ hashkeys = node->hashkeys; econtext = node->ps.ps_ExprContext; /* * get all inner tuples and insert into the hash table (or temp files) */ for (;;) { slot = ExecProcNode(outerNode); if (TupIsNull(slot)) break; /* We have to compute the hash value */ econtext->ecxt_innertuple = slot; if (ExecHashGetHashValue(hashtable, econtext, hashkeys, false, hashtable->keepNulls, &hashvalue)) { int bucketNumber; bucketNumber = ExecHashGetSkewBucket(hashtable, hashvalue); if (bucketNumber != INVALID_SKEW_BUCKET_NO) { /* It's a skew tuple, so put it into that hash table */ ExecHashSkewTableInsert(hashtable, slot, hashvalue, bucketNumber); } else { /* Not subject to skew optimization, so insert normally */ ExecHashTableInsert(hashtable, slot, hashvalue); } hashtable->totalTuples += 1; } } /* must provide our own instrumentation support */ if (node->ps.instrument) InstrStopNode(node->ps.instrument, hashtable->totalTuples); /* * We do not return the hash table directly because it's not a subtype of * Node, and so would violate the MultiExecProcNode API. Instead, our * parent Hashjoin node is expected to know how to fish it out of our node * state. Ugly but not really worth cleaning up, since Hashjoin knows * quite a bit more about Hash besides that. */ return NULL; }