Beispiel #1
0
static void setarrayvector(ktap_State *ks, Table *t, int size)
{
	int i;

	kp_realloc(ks, t->array, t->sizearray, size, Tvalue);
	for (i = t->sizearray; i < size; i++)
		setnilvalue(&t->array[i]);

	t->sizearray = size;
}
Beispiel #2
0
static void growstack(ktap_state *ks, int n)
{
	ktap_value *oldstack;
	int lim;
	ktap_callinfo *ci;
	ktap_gcobject *up;
	int size = ks->stacksize;
	int needed = (int)(ks->top - ks->stack) + n;
	int newsize = 2 * size;

	if (newsize > KTAP_MAXSTACK)
		newsize = KTAP_MAXSTACK;

	if (newsize < needed)
		newsize = needed;

	if (newsize > KTAP_MAXSTACK) {  /* stack overflow? */
		kp_error(ks, "stack overflow\n");
		return;
	}

	/* realloc stack */
	oldstack = ks->stack;
	lim = ks->stacksize;
	kp_realloc(ks, ks->stack, ks->stacksize, newsize, ktap_value);

	for (; lim < newsize; lim++)
		setnilvalue(ks->stack + lim);
	ks->stacksize = newsize;
	ks->stack_last = ks->stack + newsize;

	/* correct stack */
	ks->top = (ks->top - oldstack) + ks->stack;
	for (up = ks->openupval; up != NULL; up = up->gch.next)
		gco2uv(up)->v = (gco2uv(up)->v - oldstack) + ks->stack;

	for (ci = ks->ci; ci != NULL; ci = ci->prev) {
		ci->top = (ci->top - oldstack) + ks->stack;
		ci->func = (ci->func - oldstack) + ks->stack;
		if (isktapfunc(ci))
			ci->u.l.base = (ci->u.l.base - oldstack) + ks->stack;
	}
	
}
Beispiel #3
0
void kp_table_resize(ktap_State *ks, Table *t, int nasize, int nhsize)
{
	int i;
	int oldasize = t->sizearray;
	int oldhsize = t->lsizenode;
	Node *nold = t->node;  /* save old hash ... */

	if (nasize > oldasize)  /* array part must grow? */
		setarrayvector(ks, t, nasize);

	/* create new hash part with appropriate size */
	setnodevector(ks, t, nhsize);

	if (nasize < oldasize) {  /* array part must shrink? */
		t->sizearray = nasize;
		/* re-insert elements from vanishing slice */
		for (i=nasize; i<oldasize; i++) {
			if (!ttisnil(&t->array[i]))
				kp_table_setint(ks, t, i + 1, &t->array[i]);
		}

		/* shrink array */
		kp_realloc(ks, t->array, oldasize, nasize, Tvalue);
	}

	/* re-insert elements from hash part */
	for (i = twoto(oldhsize) - 1; i >= 0; i--) {
		Node *old = nold+i;
		if (!ttisnil(gval(old))) {
			/* doesn't need barrier/invalidate cache, as entry was
			 * already present in the table
			 */
			setobj(ks, kp_table_set(ks, t, gkey(old)), gval(old));
		}
	}

	if (!isdummy(nold))
		kp_free(ks, nold); /* free old array */
}
Beispiel #4
0
int vector_delete(vector *v, unsigned long long idx, void **e)
{
	unsigned long long i;
	int flush_size = 0;

	if (v == NULL) {
		v_error("v is NULL\n");
		return -1;
	}
	if (idx >= v->count) {
		if (VECTOR_DIE_ON_OOB) {
			v_die("index %llu out-of-bounds, v->count=%llu\n", idx, v->count);
		}
		v_error("index %llu out-of-bounds, v->count=%llu\n", idx, v->count);
		return -1;
	}

	/* Don't free the element to be deleted, but set *e to point to it
	 * so that the caller can free it. Then, shift all of the other
	 * elements in the array down one slot:
	 */
	v_debug("deleting element %s from slot %llu\n", (char *)v->data[idx], idx);
	if (e) {
		*e = v->data[idx];
	}

	/* Start at the removed index and shift elements backwards one at a
	 * time. This is somewhat "repeatable" - if a failure occurs while
	 * we're doing this, then we can either remember the shift index, or
	 * look through the array for duplicates, and then resume where we left
	 * off. We flush after every single shift (ouch!) so that no data can
	 * be lost. This is similar (but opposite) to vector_insert() above. */
	for (i = idx; i < v->count - 1; i++) {
		v->data[i] = v->data[i+1];
		kp_flush_range(&(v->data[i]), sizeof(void *), v->use_nvm);
		v_debug("shifted element %s from slot %llu down to slot %llu\n",
				(char *)(v->data[i]), i+1, i);
	}
	v->count--;
	kp_flush_range((void *)&(v->count), sizeof(unsigned long long), v->use_nvm);
	v_debug("now count=%llu, size=%llu (resize factor=%u)\n", v->count, v->size,
			VECTOR_RESIZE_FACTOR);

	/* Shrink the array if the number of used slots falls below the number
	 * of allocated slots divided by the resize factor times 2. We double
	 * the resize factor when checking this condition, but only shrink the
	 * array by a single resize factor, to avoid "pathological" behavior
	 * where the vector reaches some size and then the client repeatedly
	 * adds one element and deletes one element, causing a resize on every
	 * operation (note: this analysis is not scientific nor empirical).
	 *
	 * In the condition below, <= causes resizing to happen a bit earlier
	 * and seems better than just <. With VECTOR_RESIZE_FACTOR = 2, this
	 * logic causes the array to be cut in half when the number of elements
	 * is decreased to 1/4 of the number of allocated slots.
	 */
	if ((v->size > VECTOR_INIT_SIZE) &&
	    (v->count <= v->size / (VECTOR_RESIZE_FACTOR * 2))) {
		v_debug("count %llu is <= %llu, shrinking array\n", v->count,
				v->size / (VECTOR_RESIZE_FACTOR * 2));

		/* See notes about flush_size in vector_append() above. */
		if (v->use_nvm) {
			flush_size = offsetof(vector, count) - offsetof(vector, data);
#ifdef VECTOR_ASSERT
			if (flush_size < (sizeof(void **) + sizeof(unsigned long long))) {
				v_die("got unexpected flush_size %d! offsetof(count)=%zu, "
						"offsetof(data)=%zu\n", flush_size,
						offsetof(vector, count), offsetof(vector, data));
			}
#endif
		}

		/* We set the vector's new size first, then set its data pointer, and
		 * then finally flush them both to memory (if use_nvm is true). See
		 * the notes in vector_append() for this. */
		/* Leak window begin: */
		v->size /= VECTOR_RESIZE_FACTOR;  //inverse of vector_append()
		kp_realloc((void **)&(v->data), sizeof(void*) * v->size, v->use_nvm);
		kp_flush_range(&(v->data), flush_size, v->use_nvm);
		/* Leak window end. If we fail after the flush has returned, then
		 * the next call to vector_delete() will skip the resizing step. */
		if (v->data == NULL) {
			v_die("kp_realloc(array) failed\n");
		}
		v_debug("shrunk array, now has size %llu (%llu slots)\n",
				sizeof(void*) * v->size, v->size);
	}

	return 0;
}
Beispiel #5
0
/* CHECK - TODO: how consistent / durable / atomic / recoverable is this
 * function???
 *
 * This function allows NULL pointers for the element put into the array,
 * for now. */
uint64_t vector_insert(vector *v, const void *e, vector_comparator cmp)
{
	unsigned long long orig_size, new_size;
	uint64_t insert_idx, shift_idx;
	int flush_size = 0;

	/* HEADS UP: this function is mostly the same as vector_append(), so
	 * if you update one, you should probably update the other! */

	if (v == NULL) {
		v_error("v is NULL\n");
		return -1;
	}
	if (v->count == VECTOR_MAX_COUNT) {
		v_error("hit maximum vector length: v->count=%llu\n", v->count);
		return -1;
	}
#ifndef UNSAFE_COMMIT
//#ifdef VECTOR_ASSERT
#if 0
	/* This assert only makes sense if we're not garbage collecting or
	 * otherwise removing things from vectors. Note that the resizing
	 * code doesn't contain any explicit checks for this (it will
	 * happily reduce the size of the vector below the initial size
	 * if you remove enough things); this bhavior should probably
	 * change, but whatever. */
	if (v->size < VECTOR_INIT_SIZE) {
		v_die("vector size %llu is less than initial size %d!!\n",
				v->size, VECTOR_INIT_SIZE);
	}
#endif
#endif

	kp_todo("factor out the resizing code that's common to both append "
			"and insert, dummy!\n");

	/* When the last array slot is exhausted, increase the size of the
	 * array by multiplying it by the resize factor.
	 * Resizing the array consists of two steps: A) re-allocing the memory
	 * region, and B) setting the new size of the vector. A) is repeatable,
	 * but unfortunately could result in a memory leak if we don't correctly
	 * remember the pointer AND remember the new size! To minimize the leak
	 * window here, we immediately flush both the pointer and the size (which
	 * should be adjacent to each other in the struct!) after the realloc.
	 * We calculate the size of the flush that we need to perform by using
	 * the offsetof operator, because the compiler may insert padding between
	 * members that we don't know about. This code assumes that the order of
	 * the members in the struct is [data, size, count].
	 *
	 * ...
	 */
	if (v->size == v->count) {
#ifdef VECTOR_RESIZE_PRINT
		v_print("v->size hit v->count = %llu; insert resizing!!!\n",
				v->size);
#endif
		v_debug("v->size hit v->count = %llu; resizing!!!\n", v->size);
		/* Check if multiplying v->size by VECTOR_RESIZE_FACTOR will put
		 * it over the VECTOR_MAX_COUNT:
		 */
		if (v->size > (VECTOR_MAX_COUNT / VECTOR_RESIZE_FACTOR)) {
			v_debug("vector size (%llu) times resize factor (%d) would "
					"overflow max count (%llu), so setting size directly "
					"to max count\n", v->size, VECTOR_RESIZE_FACTOR,
					VECTOR_MAX_COUNT);
			new_size = VECTOR_MAX_COUNT;
		} else {
			new_size = v->size * VECTOR_RESIZE_FACTOR;
		}
#ifdef VECTOR_RESIZE_PRINT
		v_print("calculated new_size=%llu (insert)\n", new_size);
#endif
		orig_size = v->size;
#ifdef UNSAFE_COMMIT
		if (new_size > UNSAFE_COMMIT_LOG_SIZE) {
			v_print("WARNING: new vector size is greater than %d, probably "
					"means that we're resizing the commit_log vector!!\n",
					UNSAFE_COMMIT_LOG_SIZE);
		}
#endif
#ifdef V_ASSERT
		if (new_size > 100) {
			v_debug("WARNING: resizing vector to new_size=%llu\n", new_size);
		}
#endif

		/* We expect the flush_size to be 12, but the compiler could possibly
		 * insert padding that changes this. On brief examination, no padding
		 * is inserted and both the data pointer and the size are flushed in
		 * a single flush.
		 * todo: could put the following code segment in its own "pcm_realloc()"
		 * function...
		 */
		if (v->use_nvm) {
			/* We only need to flush data and size; count comes _after_ size,
			 * so use it as the end of the range to flush. */
			flush_size = offsetof(vector, count) - offsetof(vector, data);
			//v_print("calculated flush_size=%d from offsetof(count)=%u, "
			//		"offsetof(data)=%u\n", flush_size, offsetof(vector, count),
			//		offsetof(vector, data));
#ifdef VECTOR_ASSERT
			if (flush_size < (sizeof(void **) + sizeof(unsigned long long))) {
				v_die("got unexpected flush_size %d! offsetof(count)=%zu, "
						"offsetof(data)=%zu\n", flush_size,
						offsetof(vector, count), offsetof(vector, data));
			}
			//v_print("calculated flush_size %d from offsetof(count)=%u, "
			//		"offsetof(data)=%d\n", flush_size,
			//		offsetof(vector, count), offsetof(vector, data));
#endif
		}

		/* Leak window begin. Note that kp_realloc() doesn't flush internally,
		 * because we want to flush both the data and the size in the same
		 * cache line to get consistency
		 *   Also note that we don't currently GUARANTEE this, if the compiler
		 *   happens to allocate v->data and v->size in two different cache
		 *   lines. */
		kp_realloc((void **)&(v->data), sizeof(void*) * new_size, v->use_nvm);
		v->size = new_size;
		kp_flush_range(&(v->data), flush_size, v->use_nvm);  //flush both data and size!
		/* Leak window end. If we fail after the flush() has returned,
		 * then the next call to vector_append() will skip the resizing
		 * step.
		 */
		if (v->data == NULL) {
			v_error("kp_realloc(array) failed\n");
			/* Best effort on failure: reset size to what it was before,
			 * and let caller handle the rest.
			 */
			v->size = orig_size;
			return -1;
		}

		v_debug("re-allocated array, now has size %llu (%llu slots)\n",
				sizeof(void*) * v->size, v->size);
	}

	/* We expect that this function will often be an append anyway, so
	 * we start at the end of the array and then search backwards for the
	 * index to insert into. */
	insert_idx = v->count;
	/* The comparator function returns positive if e1 > e2. By using
	 * > and not >= here, we will stop as early as possible, so if
	 * elements happen to be equal to each other then the later elements
	 * will be further along in the array. */
	while (insert_idx > 0 && cmp(v->data[insert_idx-1], e) > 0) {
		insert_idx--;
	}
	//v_print("set insert_idx=%llu (count=%llu)\n", insert_idx, v->count);

	/* Start at the back of the array again and shift elements forward one
	 * at a time. This is somewhat "repeatable" - if a failure occurs while
	 * we're doing this, then we can either remember the shift index, or
	 * look through the array for duplicates, and then resume where we left
	 * off. We flush after every single shift (ouch!) so that no data can
	 * be lost. */
	shift_idx = v->count;
	while (shift_idx > insert_idx) {
		//v_print("shifting element from %llu to %llu\n", shift_idx-1, shift_idx);
		v->data[shift_idx] = v->data[shift_idx - 1];
		kp_flush_range(&(v->data[shift_idx]), sizeof(void *), v->use_nvm);
		shift_idx--;
	}
	//v_print("now inserting new element into idx=%llu\n", insert_idx);

	/* Use two flushes here to make this "repeatable" - if we fail after
	 * the first set + flush, there are no real effects (well, this was
	 * true for append... is it any different for insert??). */
	v->data[insert_idx] = (void *)e;
	kp_flush_range(&(v->data[insert_idx]), sizeof(void *), v->use_nvm);
	v->count++;
	kp_flush_range(&(v->count), sizeof(unsigned long long), v->use_nvm);
	//v_print("stored new element %s in slot %llu (now count=%llu, size=%llu)\n",
	//		(char *)(v->data[insert_idx]), insert_idx, v->count, v->size);
	//v_print("stored new element %p in slot %llu (now count=%llu, size=%llu)\n",
	//		v->data[insert_idx], insert_idx, v->count, v->size);

	return insert_idx;
}
Beispiel #6
0
/* Ideally, vector_append would be consistent, durable, and _atomic_, which
 * would mean that it doesn't have to be _recovered_ after a failure. This
 * is probably possible by following the instructions in "A Lock-Free
 * Dynamically Resizable Array." However, this would require a significant
 * restructuring of the vector code that we already have, so we won't do
 * this for now. Instead, when the vector needs resizing, we focus on making
 * it _recoverable_, rather than atomic; when the vector doesn't need resizing,
 * then append is consistent and durable and _repeatable_, rather than atomic.
 *
 * Note that vector_append is NOT thread-safe or "lock-free" - high-level
 * synchronization is needed so that only one append occurs at a time!
 *
 * Relevant links:
 *   http://www2.research.att.com/~bs/lock-free-vector.pdf
 *   https://parasol.tamu.edu/~peterp/slides/opodis06.pdf
 *   Intel patent, 8006064: "Lock-free vector utilizing a resource allocator...":
 *     http://www.google.com/patents/US8006064?printsec=abstract#v=onepage&q&f=false
 *   http://www.ibm.com/developerworks/aix/library/au-intelthreadbuilding/index.html?ca=drs-
 *   http://software.intel.com/en-us/blogs/2009/04/09/delusion-of-tbbconcurrent_vectors-size-or-3-ways-to-traverse-in-parallel-correctly/
 *
 * This function allows NULL pointers for the element put into the array,
 * for now. 
 *
 * NOTE: for version 3.1 (simultaneous merges with conflict detection), I
 * hacked this interface to return the element that used to be the last
 * element in the vector, before we appended this one. Hmmm...
 */
int vector_append(vector *v, const void *e, void **previous_tail)
{
	unsigned long long orig_size, new_size;
	int flush_size = 0;

	/* HEADS UP: this function is mostly the same as vector_insert(), so
	 * if you update one, you should probably update the other! */

	if (v == NULL) {
		v_error("v is NULL\n");
		return -1;
	}
	if (v->count == VECTOR_MAX_COUNT) {
		v_error("hit maximum vector length: v->count=%llu\n", v->count);
		return -1;
	}
#ifndef UNSAFE_COMMIT
//#ifdef VECTOR_ASSERT
#if 0
	/* This assert only makes sense if we're not garbage collecting or
	 * otherwise removing things from vectors. Note that the resizing
	 * code doesn't contain any explicit checks for this (it will
	 * happily reduce the size of the vector below the initial size
	 * if you remove enough things); maybe this behavior should change,
	 * but whatever. */
	if (v->size < VECTOR_INIT_SIZE) {
		v_die("vector size %llu is less than initial size %d!!\n",
				v->size, VECTOR_INIT_SIZE);
	}
#endif
#endif

	/* When the last array slot is exhausted, increase the size of the
	 * array by multiplying it by the resize factor.
	 * Resizing the array consists of two steps: A) re-allocing the memory
	 * region, and B) setting the new size of the vector. A) is repeatable,
	 * but unfortunately could result in a memory leak if we don't correctly
	 * remember the pointer AND remember the new size! To minimize the leak
	 * window here, we immediately flush both the pointer and the size (which
	 * should be adjacent to each other in the struct!) after the realloc.
	 * We calculate the size of the flush that we need to perform by using
	 * the offsetof operator, because the compiler may insert padding between
	 * members that we don't know about. This code assumes that the order of
	 * the members in the struct is [data, size, count].
	 *
	 * ...
	 */
	if (v->size == v->count) {
#ifdef VECTOR_RESIZE_PRINT
		v_print("v->size hit v->count = %llu; append resizing!!!\n",
				v->size);
#endif
		v_debug("v->size hit v->count = %llu; resizing!!!\n", v->size);
		/* Check if multiplying v->size by VECTOR_RESIZE_FACTOR will put
		 * it over the VECTOR_MAX_COUNT:
		 */
		if (v->size > (VECTOR_MAX_COUNT / VECTOR_RESIZE_FACTOR)) {
			v_debug("vector size (%llu) times resize factor (%d) would "
					"overflow max count (%llu), so setting size directly "
					"to max count\n", v->size, VECTOR_RESIZE_FACTOR,
					VECTOR_MAX_COUNT);
			new_size = VECTOR_MAX_COUNT;
		} else {
			new_size = v->size * VECTOR_RESIZE_FACTOR;
		}
#ifdef VECTOR_RESIZE_PRINT
		v_print("calculated new_size=%llu (append)\n", new_size);
#endif
		orig_size = v->size;
#ifdef UNSAFE_COMMIT
		if (new_size > UNSAFE_COMMIT_LOG_SIZE) {
			v_print("WARNING: new vector size is greater than %d, probably "
					"means that we're resizing the commit_log vector!!\n",
					UNSAFE_COMMIT_LOG_SIZE);
		}
#endif
#ifdef V_ASSERT
		if (new_size > 100) {
			v_debug("WARNING: resizing vector to new_size=%llu\n", new_size);
		}
#endif

		/* We expect the flush_size to be 12, but the compiler could possibly
		 * insert padding that changes this. On brief examination, no padding
		 * is inserted and both the data pointer and the size are flushed in
		 * a single flush.
		 * todo: could put the following code segment in its own "pcm_realloc()"
		 * function...
		 */
		if (v->use_nvm) {
			/* We only need to flush data and size; count comes _after_ size,
			 * so use it as the end of the range to flush. */
			flush_size = offsetof(vector, count) - offsetof(vector, data);
#ifdef VECTOR_ASSERT
			if (flush_size < (sizeof(void **) + sizeof(unsigned long long))) {
				v_die("got unexpected flush_size %d! offsetof(count)=%zu, "
						"offsetof(data)=%zu\n", flush_size,
						offsetof(vector, count), offsetof(vector, data));
			}
			//v_print("calculated flush_size %d from offsetof(count)=%u, "
			//		"offsetof(data)=%d\n", flush_size,
			//		offsetof(vector, count), offsetof(vector, data));
#endif
		}

		/* Leak window begin. Note that kp_realloc() doesn't flush internally,
		 * because we want to flush both the data and the size in the same
		 * cache line to get consistency
		 *   Also note that we don't currently GUARANTEE this, if the compiler
		 *   happens to allocate v->data and v->size in two different cache
		 *   lines. */
		kp_realloc((void **)&(v->data), sizeof(void*) * new_size, v->use_nvm);
		v->size = new_size;
		kp_flush_range(&(v->data), flush_size, v->use_nvm);  //flush both data and size!
		/* Leak window end. If we fail after the flush() has returned,
		 * then the next call to vector_append() will skip the resizing
		 * step.
		 */
		if (v->data == NULL) {
			v_error("kp_realloc(array) failed\n");
			/* Best effort on failure: reset size to what it was before,
			 * and let caller handle the rest.
			 */
			v->size = orig_size;
			return -1;
		}

		v_debug("re-allocated array, now has size %llu (%llu slots)\n",
				sizeof(void*) * v->size, v->size);
	}

	/* The actual append part of vector_append() is repeatable: we first
	 * fill in the element in the data array, then increment the count.
	 * If we fail in-between these two steps, then vector_append() can
	 * just be called again and we'll overwrite the memory area with the
	 * same value. We do, however, have to flush the written element before
	 * incrementing the count: we don't want the incremented count to hit
	 * memory before the new element does.
	 * ACTUALLY, this makes the vector_append ATOMIC, not repeatable (right?).
	 * After a failure, if the caller didn't get a return value from this
	 * function, then it can't be certain whether or not the append succeeded,
	 * and so it should probably do a vector_get() to check if the append
	 * happened or not.
	 */
	if (previous_tail) {  //super hacky
		if (v->count > 0) {
			*previous_tail = v->data[v->count - 1];
		} else {
			*previous_tail = NULL;
		}
		/* Don't need to flush; caller will do it... */
	}

	/* Use two flushes here to make this "repeatable" - if we fail after
	 * the first set + flush, there are no real effects. */
	v->data[v->count] = (void *)e;
	kp_flush_range(&(v->data[v->count]), sizeof(void *), v->use_nvm);
	/* Do we need a memory fence right here? Only if we're flushing (so
	 * the fence is already internal in kp_flush_range()); otherwise,
	 * we're not concerned about anybody else seeing the count and the
	 * element out-of-order... (right?). */
	v->count++;
	kp_flush_range((void *)&(v->count), sizeof(unsigned long long), v->use_nvm);
	v_debug("stored new element %s in slot %llu (now count=%llu, size=%llu)\n",
			(char *)(v->data[(v->count)-1]), v->count-1, v->count, v->size);

	return 0;
}