You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@mynewt.apache.org by ad...@apache.org on 2016/06/16 21:41:19 UTC

[11/51] [partial] incubator-mynewt-site git commit: remove untarred files for openocd

http://git-wip-us.apache.org/repos/asf/incubator-mynewt-site/blob/69f466b5/docs/os/tutorials/downloads/openocd-code-89bf96ffe6ac66c80407af8383b9d5adc0dc35f4/src/helper/binarybuffer.h
----------------------------------------------------------------------
diff --git a/docs/os/tutorials/downloads/openocd-code-89bf96ffe6ac66c80407af8383b9d5adc0dc35f4/src/helper/binarybuffer.h b/docs/os/tutorials/downloads/openocd-code-89bf96ffe6ac66c80407af8383b9d5adc0dc35f4/src/helper/binarybuffer.h
deleted file mode 100755
index eaa8c52..0000000
--- a/docs/os/tutorials/downloads/openocd-code-89bf96ffe6ac66c80407af8383b9d5adc0dc35f4/src/helper/binarybuffer.h
+++ /dev/null
@@ -1,243 +0,0 @@
-/***************************************************************************
- *   Copyright (C) 2004, 2005 by Dominic Rath                              *
- *   Dominic.Rath@gmx.de                                                   *
- *                                                                         *
- *   Copyright (C) 2007,2008 �yvind Harboe                                 *
- *   oyvind.harboe@zylin.com                                               *
- *                                                                         *
- *   This program is free software; you can redistribute it and/or modify  *
- *   it under the terms of the GNU General Public License as published by  *
- *   the Free Software Foundation; either version 2 of the License, or     *
- *   (at your option) any later version.                                   *
- *                                                                         *
- *   This program is distributed in the hope that it will be useful,       *
- *   but WITHOUT ANY WARRANTY; without even the implied warranty of        *
- *   MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE.  See the         *
- *   GNU General Public License for more details.                          *
- *                                                                         *
- *   You should have received a copy of the GNU General Public License     *
- *   along with this program; if not, write to the                         *
- *   Free Software Foundation, Inc.,                                       *
- *   51 Franklin Street, Fifth Floor, Boston, MA 02110-1301 USA.           *
- ***************************************************************************/
-
-#ifndef BINARYBUFFER_H
-#define BINARYBUFFER_H
-
-#include "list.h"
-
-/** @file
- * Support functions to access arbitrary bits in a byte array
- */
-
-/**
- * Sets @c num bits in @c _buffer, starting at the @c first bit,
- * using the bits in @c value.  This routine fast-paths writes
- * of little-endian, byte-aligned, 32-bit words.
- * @param _buffer The buffer whose bits will be set.
- * @param first The bit offset in @c _buffer to start writing (0-31).
- * @param num The number of bits from @c value to copy (1-32).
- * @param value Up to 32 bits that will be copied to _buffer.
- */
-static inline void buf_set_u32(uint8_t *_buffer,
-	unsigned first, unsigned num, uint32_t value)
-{
-	uint8_t *buffer = _buffer;
-
-	if ((num == 32) && (first == 0)) {
-		buffer[3] = (value >> 24) & 0xff;
-		buffer[2] = (value >> 16) & 0xff;
-		buffer[1] = (value >> 8) & 0xff;
-		buffer[0] = (value >> 0) & 0xff;
-	} else {
-		for (unsigned i = first; i < first + num; i++) {
-			if (((value >> (i - first)) & 1) == 1)
-				buffer[i / 8] |= 1 << (i % 8);
-			else
-				buffer[i / 8] &= ~(1 << (i % 8));
-		}
-	}
-}
-
-/**
- * Sets @c num bits in @c _buffer, starting at the @c first bit,
- * using the bits in @c value.  This routine fast-paths writes
- * of little-endian, byte-aligned, 64-bit words.
- * @param _buffer The buffer whose bits will be set.
- * @param first The bit offset in @c _buffer to start writing (0-63).
- * @param num The number of bits from @c value to copy (1-64).
- * @param value Up to 64 bits that will be copied to _buffer.
- */
-static inline void buf_set_u64(uint8_t *_buffer,
-	unsigned first, unsigned num, uint64_t value)
-{
-	uint8_t *buffer = _buffer;
-
-	if ((num == 32) && (first == 0)) {
-		buffer[3] = (value >> 24) & 0xff;
-		buffer[2] = (value >> 16) & 0xff;
-		buffer[1] = (value >> 8) & 0xff;
-		buffer[0] = (value >> 0) & 0xff;
-	} else if ((num == 64) && (first == 0)) {
-		buffer[7] = (value >> 56) & 0xff;
-		buffer[6] = (value >> 48) & 0xff;
-		buffer[5] = (value >> 40) & 0xff;
-		buffer[4] = (value >> 32) & 0xff;
-		buffer[3] = (value >> 24) & 0xff;
-		buffer[2] = (value >> 16) & 0xff;
-		buffer[1] = (value >> 8) & 0xff;
-		buffer[0] = (value >> 0) & 0xff;
-	} else {
-		for (unsigned i = first; i < first + num; i++) {
-			if (((value >> (i - first)) & 1) == 1)
-				buffer[i / 8] |= 1 << (i % 8);
-			else
-				buffer[i / 8] &= ~(1 << (i % 8));
-		}
-	}
-}
-
-/**
- * Retrieves @c num bits from @c _buffer, starting at the @c first bit,
- * returning the bits in a 32-bit word.  This routine fast-paths reads
- * of little-endian, byte-aligned, 32-bit words.
- * @param _buffer The buffer whose bits will be read.
- * @param first The bit offset in @c _buffer to start reading (0-31).
- * @param num The number of bits from @c _buffer to read (1-32).
- * @returns Up to 32-bits that were read from @c _buffer.
- */
-static inline uint32_t buf_get_u32(const uint8_t *_buffer,
-	unsigned first, unsigned num)
-{
-	const uint8_t *buffer = _buffer;
-
-	if ((num == 32) && (first == 0)) {
-		return (((uint32_t)buffer[3]) << 24) |
-				(((uint32_t)buffer[2]) << 16) |
-				(((uint32_t)buffer[1]) << 8) |
-				(((uint32_t)buffer[0]) << 0);
-	} else {
-		uint32_t result = 0;
-		for (unsigned i = first; i < first + num; i++) {
-			if (((buffer[i / 8] >> (i % 8)) & 1) == 1)
-				result |= 1 << (i - first);
-		}
-		return result;
-	}
-}
-
-/**
- * Retrieves @c num bits from @c _buffer, starting at the @c first bit,
- * returning the bits in a 64-bit word.  This routine fast-paths reads
- * of little-endian, byte-aligned, 64-bit words.
- * @param _buffer The buffer whose bits will be read.
- * @param first The bit offset in @c _buffer to start reading (0-63).
- * @param num The number of bits from @c _buffer to read (1-64).
- * @returns Up to 64-bits that were read from @c _buffer.
- */
-static inline uint64_t buf_get_u64(const uint8_t *_buffer,
-	unsigned first, unsigned num)
-{
-	const uint8_t *buffer = _buffer;
-
-	if ((num == 32) && (first == 0)) {
-		return 0 + ((((uint32_t)buffer[3]) << 24) |   /* Note - zero plus is to avoid a checkpatch bug */
-				(((uint32_t)buffer[2]) << 16) |
-				(((uint32_t)buffer[1]) << 8)  |
-				(((uint32_t)buffer[0]) << 0));
-	} else if ((num == 64) && (first == 0)) {
-		return 0 + ((((uint64_t)buffer[7]) << 56) |   /* Note - zero plus is to avoid a checkpatch bug */
-				(((uint64_t)buffer[6]) << 48) |
-				(((uint64_t)buffer[5]) << 40) |
-				(((uint64_t)buffer[4]) << 32) |
-				(((uint64_t)buffer[3]) << 24) |
-				(((uint64_t)buffer[2]) << 16) |
-				(((uint64_t)buffer[1]) << 8)  |
-				(((uint64_t)buffer[0]) << 0));
-	} else {
-		uint64_t result = 0;
-		for (unsigned i = first; i < first + num; i++) {
-			if (((buffer[i / 8] >> (i % 8)) & 1) == 1)
-				result = result | ((uint64_t)1 << (uint64_t)(i - first));
-		}
-		return result;
-	}
-}
-
-
-/**
- * Inverts the ordering of bits inside a 32-bit word (e.g. 31..0 -> 0..31).
- * This routine can be used to flip smaller data types by using smaller
- * values for @c width.
- * @param value The word to flip.
- * @param width The number of bits in value (2-32).
- * @returns A 32-bit word with @c value in reversed bit-order.
- */
-uint32_t flip_u32(uint32_t value, unsigned width);
-
-bool buf_cmp(const void *buf1, const void *buf2, unsigned size);
-bool buf_cmp_mask(const void *buf1, const void *buf2,
-		const void *mask, unsigned size);
-
-/**
- * Copies @c size bits out of @c from and into @c to.  Any extra
- * bits in the final byte will be set to zero.
- * @param from The buffer to copy into @c to.
- * @param to The buffer that will receive the copy of @c from.
- * @param size The number of bits to copy.
- */
-void *buf_cpy(const void *from, void *to, unsigned size);
-
-/**
- * Set the contents of @c buf with @c count bits, all set to 1.
- * @param buf The buffer to fill with ones.
- * @param size The number of bits.
- * @returns The original buffer (@c buf).
- */
-void *buf_set_ones(void *buf, unsigned size);
-
-void *buf_set_buf(const void *src, unsigned src_start,
-		  void *dst, unsigned dst_start, unsigned len);
-
-int str_to_buf(const char *str, unsigned len,
-		void *bin_buf, unsigned buf_size, unsigned radix);
-char *buf_to_str(const void *buf, unsigned size, unsigned radix);
-
-/* read a uint32_t from a buffer in target memory endianness */
-static inline uint32_t fast_target_buffer_get_u32(const void *p, bool le)
-{
-	return le ? le_to_h_u32(p) : be_to_h_u32(p);
-}
-
-static inline void bit_copy(uint8_t *dst, unsigned dst_offset, const uint8_t *src,
-	unsigned src_offset, unsigned bit_count)
-{
-	buf_set_buf(src, src_offset, dst, dst_offset, bit_count);
-}
-
-struct bit_copy_queue {
-	struct list_head list;
-};
-
-struct bit_copy_queue_entry {
-	uint8_t *dst;
-	unsigned dst_offset;
-	const uint8_t *src;
-	unsigned src_offset;
-	unsigned bit_count;
-	struct list_head list;
-};
-
-void bit_copy_queue_init(struct bit_copy_queue *q);
-int bit_copy_queued(struct bit_copy_queue *q, uint8_t *dst, unsigned dst_offset, const uint8_t *src,
-		    unsigned src_offset, unsigned bit_count);
-void bit_copy_execute(struct bit_copy_queue *q);
-void bit_copy_discard(struct bit_copy_queue *q);
-
-/* functions to convert to/from hex encoded buffer
- * used in ti-icdi driver and gdb server */
-int unhexify(char *bin, const char *hex, int count);
-int hexify(char *hex, const char *bin, int count, int out_maxlen);
-void buffer_shr(void *_buf, unsigned buf_len, unsigned count);
-
-#endif /* BINARYBUFFER_H */

http://git-wip-us.apache.org/repos/asf/incubator-mynewt-site/blob/69f466b5/docs/os/tutorials/downloads/openocd-code-89bf96ffe6ac66c80407af8383b9d5adc0dc35f4/src/helper/command.c
----------------------------------------------------------------------
diff --git a/docs/os/tutorials/downloads/openocd-code-89bf96ffe6ac66c80407af8383b9d5adc0dc35f4/src/helper/command.c b/docs/os/tutorials/downloads/openocd-code-89bf96ffe6ac66c80407af8383b9d5adc0dc35f4/src/helper/command.c
deleted file mode 100755
index a0aa9e8..0000000
--- a/docs/os/tutorials/downloads/openocd-code-89bf96ffe6ac66c80407af8383b9d5adc0dc35f4/src/helper/command.c
+++ /dev/null
@@ -1,1468 +0,0 @@
-/***************************************************************************
- *   Copyright (C) 2005 by Dominic Rath                                    *
- *   Dominic.Rath@gmx.de                                                   *
- *                                                                         *
- *   Copyright (C) 2007,2008 �yvind Harboe                                 *
- *   oyvind.harboe@zylin.com                                               *
- *                                                                         *
- *   Copyright (C) 2008, Duane Ellis                                       *
- *   openocd@duaneeellis.com                                               *
- *                                                                         *
- *   part of this file is taken from libcli (libcli.sourceforge.net)       *
- *   Copyright (C) David Parrish (david@dparrish.com)                      *
- *                                                                         *
- *   This program is free software; you can redistribute it and/or modify  *
- *   it under the terms of the GNU General Public License as published by  *
- *   the Free Software Foundation; either version 2 of the License, or     *
- *   (at your option) any later version.                                   *
- *                                                                         *
- *   This program is distributed in the hope that it will be useful,       *
- *   but WITHOUT ANY WARRANTY; without even the implied warranty of        *
- *   MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE.  See the         *
- *   GNU General Public License for more details.                          *
- *                                                                         *
- *   You should have received a copy of the GNU General Public License     *
- *   along with this program; if not, write to the                         *
- *   Free Software Foundation, Inc.,                                       *
- *   51 Franklin Street, Fifth Floor, Boston, MA 02110-1301 USA.           *
- ***************************************************************************/
-
-#ifdef HAVE_CONFIG_H
-#include "config.h"
-#endif
-
-/* see Embedded-HOWTO.txt in Jim Tcl project hosted on BerliOS*/
-#define JIM_EMBEDDED
-
-/* @todo the inclusion of target.h here is a layering violation */
-#include <jtag/jtag.h>
-#include <target/target.h>
-#include "command.h"
-#include "configuration.h"
-#include "log.h"
-#include "time_support.h"
-#include "jim-eventloop.h"
-
-/* nice short description of source file */
-#define __THIS__FILE__ "command.c"
-
-static int run_command(struct command_context *context,
-		struct command *c, const char *words[], unsigned num_words);
-
-struct log_capture_state {
-	Jim_Interp *interp;
-	Jim_Obj *output;
-};
-
-static void tcl_output(void *privData, const char *file, unsigned line,
-	const char *function, const char *string)
-{
-	struct log_capture_state *state = privData;
-	Jim_AppendString(state->interp, state->output, string, strlen(string));
-}
-
-static struct log_capture_state *command_log_capture_start(Jim_Interp *interp)
-{
-	/* capture log output and return it. A garbage collect can
-	 * happen, so we need a reference count to this object */
-	Jim_Obj *tclOutput = Jim_NewStringObj(interp, "", 0);
-	if (NULL == tclOutput)
-		return NULL;
-
-	struct log_capture_state *state = malloc(sizeof(*state));
-	if (NULL == state)
-		return NULL;
-
-	state->interp = interp;
-	Jim_IncrRefCount(tclOutput);
-	state->output = tclOutput;
-
-	log_add_callback(tcl_output, state);
-
-	return state;
-}
-
-/* Classic openocd commands provide progress output which we
- * will capture and return as a Tcl return value.
- *
- * However, if a non-openocd command has been invoked, then it
- * makes sense to return the tcl return value from that command.
- *
- * The tcl return value is empty for openocd commands that provide
- * progress output.
- *
- * Therefore we set the tcl return value only if we actually
- * captured output.
- */
-static void command_log_capture_finish(struct log_capture_state *state)
-{
-	if (NULL == state)
-		return;
-
-	log_remove_callback(tcl_output, state);
-
-	int length;
-	Jim_GetString(state->output, &length);
-
-	if (length > 0)
-		Jim_SetResult(state->interp, state->output);
-	else {
-		/* No output captured, use tcl return value (which could
-		 * be empty too). */
-	}
-	Jim_DecrRefCount(state->interp, state->output);
-
-	free(state);
-}
-
-static int command_retval_set(Jim_Interp *interp, int retval)
-{
-	int *return_retval = Jim_GetAssocData(interp, "retval");
-	if (return_retval != NULL)
-		*return_retval = retval;
-
-	return (retval == ERROR_OK) ? JIM_OK : retval;
-}
-
-extern struct command_context *global_cmd_ctx;
-
-/* dump a single line to the log for the command.
- * Do nothing in case we are not at debug level 3 */
-void script_debug(Jim_Interp *interp, const char *name,
-	unsigned argc, Jim_Obj * const *argv)
-{
-	if (debug_level < LOG_LVL_DEBUG)
-		return;
-
-	char *dbg = alloc_printf("command - %s", name);
-	for (unsigned i = 0; i < argc; i++) {
-		int len;
-		const char *w = Jim_GetString(argv[i], &len);
-		char *t = alloc_printf("%s %s", dbg, w);
-		free(dbg);
-		dbg = t;
-	}
-	LOG_DEBUG("%s", dbg);
-	free(dbg);
-}
-
-static void script_command_args_free(char **words, unsigned nwords)
-{
-	for (unsigned i = 0; i < nwords; i++)
-		free(words[i]);
-	free(words);
-}
-
-static char **script_command_args_alloc(
-	unsigned argc, Jim_Obj * const *argv, unsigned *nwords)
-{
-	char **words = malloc(argc * sizeof(char *));
-	if (NULL == words)
-		return NULL;
-
-	unsigned i;
-	for (i = 0; i < argc; i++) {
-		int len;
-		const char *w = Jim_GetString(argv[i], &len);
-		words[i] = strdup(w);
-		if (words[i] == NULL) {
-			script_command_args_free(words, i);
-			return NULL;
-		}
-	}
-	*nwords = i;
-	return words;
-}
-
-struct command_context *current_command_context(Jim_Interp *interp)
-{
-	/* grab the command context from the associated data */
-	struct command_context *cmd_ctx = Jim_GetAssocData(interp, "context");
-	if (NULL == cmd_ctx) {
-		/* Tcl can invoke commands directly instead of via command_run_line(). This would
-		 * happen when the Jim Tcl interpreter is provided by eCos or if we are running
-		 * commands in a startup script.
-		 *
-		 * A telnet or gdb server would provide a non-default command context to
-		 * handle piping of error output, have a separate current target, etc.
-		 */
-		cmd_ctx = global_cmd_ctx;
-	}
-	return cmd_ctx;
-}
-
-static int script_command_run(Jim_Interp *interp,
-	int argc, Jim_Obj * const *argv, struct command *c, bool capture)
-{
-	target_call_timer_callbacks_now();
-	LOG_USER_N("%s", "");	/* Keep GDB connection alive*/
-
-	unsigned nwords;
-	char **words = script_command_args_alloc(argc, argv, &nwords);
-	if (NULL == words)
-		return JIM_ERR;
-
-	struct log_capture_state *state = NULL;
-	if (capture)
-		state = command_log_capture_start(interp);
-
-	struct command_context *cmd_ctx = current_command_context(interp);
-	int retval = run_command(cmd_ctx, c, (const char **)words, nwords);
-
-	command_log_capture_finish(state);
-
-	script_command_args_free(words, nwords);
-	return command_retval_set(interp, retval);
-}
-
-static int script_command(Jim_Interp *interp, int argc, Jim_Obj *const *argv)
-{
-	/* the private data is stashed in the interp structure */
-
-	struct command *c = interp->cmdPrivData;
-	assert(c);
-	script_debug(interp, c->name, argc, argv);
-	return script_command_run(interp, argc, argv, c, true);
-}
-
-static struct command *command_root(struct command *c)
-{
-	while (NULL != c->parent)
-		c = c->parent;
-	return c;
-}
-
-/**
- * Find a command by name from a list of commands.
- * @returns Returns the named command if it exists in the list.
- * Returns NULL otherwise.
- */
-static struct command *command_find(struct command *head, const char *name)
-{
-	for (struct command *cc = head; cc; cc = cc->next) {
-		if (strcmp(cc->name, name) == 0)
-			return cc;
-	}
-	return NULL;
-}
-
-struct command *command_find_in_context(struct command_context *cmd_ctx,
-	const char *name)
-{
-	return command_find(cmd_ctx->commands, name);
-}
-struct command *command_find_in_parent(struct command *parent,
-	const char *name)
-{
-	return command_find(parent->children, name);
-}
-
-/**
- * Add the command into the linked list, sorted by name.
- * @param head Address to head of command list pointer, which may be
- * updated if @c c gets inserted at the beginning of the list.
- * @param c The command to add to the list pointed to by @c head.
- */
-static void command_add_child(struct command **head, struct command *c)
-{
-	assert(head);
-	if (NULL == *head) {
-		*head = c;
-		return;
-	}
-
-	while ((*head)->next && (strcmp(c->name, (*head)->name) > 0))
-		head = &(*head)->next;
-
-	if (strcmp(c->name, (*head)->name) > 0) {
-		c->next = (*head)->next;
-		(*head)->next = c;
-	} else {
-		c->next = *head;
-		*head = c;
-	}
-}
-
-static struct command **command_list_for_parent(
-	struct command_context *cmd_ctx, struct command *parent)
-{
-	return parent ? &parent->children : &cmd_ctx->commands;
-}
-
-static void command_free(struct command *c)
-{
-	/** @todo if command has a handler, unregister its jim command! */
-
-	while (NULL != c->children) {
-		struct command *tmp = c->children;
-		c->children = tmp->next;
-		command_free(tmp);
-	}
-
-	free(c->name);
-	free(c->help);
-	free(c->usage);
-	free(c);
-}
-
-static struct command *command_new(struct command_context *cmd_ctx,
-	struct command *parent, const struct command_registration *cr)
-{
-	assert(cr->name);
-
-	/*
-	 * If it is a non-jim command with no .usage specified,
-	 * log an error.
-	 *
-	 * strlen(.usage) == 0 means that the command takes no
-	 * arguments.
-	*/
-	if ((cr->jim_handler == NULL) && (cr->usage == NULL)) {
-		LOG_DEBUG("BUG: command '%s%s%s' does not have the "
-			"'.usage' field filled out",
-			parent && parent->name ? parent->name : "",
-			parent && parent->name ? " " : "",
-			cr->name);
-	}
-
-	struct command *c = calloc(1, sizeof(struct command));
-	if (NULL == c)
-		return NULL;
-
-	c->name = strdup(cr->name);
-	if (cr->help)
-		c->help = strdup(cr->help);
-	if (cr->usage)
-		c->usage = strdup(cr->usage);
-
-	if (!c->name || (cr->help && !c->help) || (cr->usage && !c->usage))
-		goto command_new_error;
-
-	c->parent = parent;
-	c->handler = cr->handler;
-	c->jim_handler = cr->jim_handler;
-	c->jim_handler_data = cr->jim_handler_data;
-	c->mode = cr->mode;
-
-	command_add_child(command_list_for_parent(cmd_ctx, parent), c);
-
-	return c;
-
-command_new_error:
-	command_free(c);
-	return NULL;
-}
-
-static int command_unknown(Jim_Interp *interp, int argc, Jim_Obj *const *argv);
-
-static int register_command_handler(struct command_context *cmd_ctx,
-	struct command *c)
-{
-	Jim_Interp *interp = cmd_ctx->interp;
-	char *ocd_name = alloc_printf("ocd_%s", c->name);
-	if (NULL == ocd_name)
-		return JIM_ERR;
-
-	LOG_DEBUG("registering '%s'...", ocd_name);
-
-	Jim_CmdProc *func = c->handler ? &script_command : &command_unknown;
-	int retval = Jim_CreateCommand(interp, ocd_name, func, c, NULL);
-	free(ocd_name);
-	if (JIM_OK != retval)
-		return retval;
-
-	/* we now need to add an overrideable proc */
-	char *override_name = alloc_printf(
-			"proc %s {args} {eval ocd_bouncer %s $args}",
-			c->name, c->name);
-	if (NULL == override_name)
-		return JIM_ERR;
-
-	retval = Jim_Eval_Named(interp, override_name, 0, 0);
-	free(override_name);
-
-	return retval;
-}
-
-struct command *register_command(struct command_context *context,
-	struct command *parent, const struct command_registration *cr)
-{
-	if (!context || !cr->name)
-		return NULL;
-
-	const char *name = cr->name;
-	struct command **head = command_list_for_parent(context, parent);
-	struct command *c = command_find(*head, name);
-	if (NULL != c) {
-		/* TODO: originally we treated attempting to register a cmd twice as an error
-		 * Sometimes we need this behaviour, such as with flash banks.
-		 * http://www.mail-archive.com/openocd-development@lists.berlios.de/msg11152.html */
-		LOG_DEBUG("command '%s' is already registered in '%s' context",
-			name, parent ? parent->name : "<global>");
-		return c;
-	}
-
-	c = command_new(context, parent, cr);
-	if (NULL == c)
-		return NULL;
-
-	int retval = ERROR_OK;
-	if (NULL != cr->jim_handler && NULL == parent) {
-		retval = Jim_CreateCommand(context->interp, cr->name,
-				cr->jim_handler, cr->jim_handler_data, NULL);
-	} else if (NULL != cr->handler || NULL != parent)
-		retval = register_command_handler(context, command_root(c));
-
-	if (ERROR_OK != retval) {
-		unregister_command(context, parent, name);
-		c = NULL;
-	}
-	return c;
-}
-
-int register_commands(struct command_context *cmd_ctx, struct command *parent,
-	const struct command_registration *cmds)
-{
-	int retval = ERROR_OK;
-	unsigned i;
-	for (i = 0; cmds[i].name || cmds[i].chain; i++) {
-		const struct command_registration *cr = cmds + i;
-
-		struct command *c = NULL;
-		if (NULL != cr->name) {
-			c = register_command(cmd_ctx, parent, cr);
-			if (NULL == c) {
-				retval = ERROR_FAIL;
-				break;
-			}
-		}
-		if (NULL != cr->chain) {
-			struct command *p = c ? : parent;
-			retval = register_commands(cmd_ctx, p, cr->chain);
-			if (ERROR_OK != retval)
-				break;
-		}
-	}
-	if (ERROR_OK != retval) {
-		for (unsigned j = 0; j < i; j++)
-			unregister_command(cmd_ctx, parent, cmds[j].name);
-	}
-	return retval;
-}
-
-int unregister_all_commands(struct command_context *context,
-	struct command *parent)
-{
-	if (context == NULL)
-		return ERROR_OK;
-
-	struct command **head = command_list_for_parent(context, parent);
-	while (NULL != *head) {
-		struct command *tmp = *head;
-		*head = tmp->next;
-		command_free(tmp);
-	}
-
-	return ERROR_OK;
-}
-
-int unregister_command(struct command_context *context,
-	struct command *parent, const char *name)
-{
-	if ((!context) || (!name))
-		return ERROR_COMMAND_SYNTAX_ERROR;
-
-	struct command *p = NULL;
-	struct command **head = command_list_for_parent(context, parent);
-	for (struct command *c = *head; NULL != c; p = c, c = c->next) {
-		if (strcmp(name, c->name) != 0)
-			continue;
-
-		if (p)
-			p->next = c->next;
-		else
-			*head = c->next;
-
-		command_free(c);
-		return ERROR_OK;
-	}
-
-	return ERROR_OK;
-}
-
-void command_set_handler_data(struct command *c, void *p)
-{
-	if (NULL != c->handler || NULL != c->jim_handler)
-		c->jim_handler_data = p;
-	for (struct command *cc = c->children; NULL != cc; cc = cc->next)
-		command_set_handler_data(cc, p);
-}
-
-void command_output_text(struct command_context *context, const char *data)
-{
-	if (context && context->output_handler && data)
-		context->output_handler(context, data);
-}
-
-void command_print_sameline(struct command_context *context, const char *format, ...)
-{
-	char *string;
-
-	va_list ap;
-	va_start(ap, format);
-
-	string = alloc_vprintf(format, ap);
-	if (string != NULL) {
-		/* we want this collected in the log + we also want to pick it up as a tcl return
-		 * value.
-		 *
-		 * The latter bit isn't precisely neat, but will do for now.
-		 */
-		LOG_USER_N("%s", string);
-		/* We already printed it above
-		 * command_output_text(context, string); */
-		free(string);
-	}
-
-	va_end(ap);
-}
-
-void command_print(struct command_context *context, const char *format, ...)
-{
-	char *string;
-
-	va_list ap;
-	va_start(ap, format);
-
-	string = alloc_vprintf(format, ap);
-	if (string != NULL) {
-		strcat(string, "\n");	/* alloc_vprintf guaranteed the buffer to be at least one
-					 *char longer */
-		/* we want this collected in the log + we also want to pick it up as a tcl return
-		 * value.
-		 *
-		 * The latter bit isn't precisely neat, but will do for now.
-		 */
-		LOG_USER_N("%s", string);
-		/* We already printed it above
-		 * command_output_text(context, string); */
-		free(string);
-	}
-
-	va_end(ap);
-}
-
-static char *__command_name(struct command *c, char delim, unsigned extra)
-{
-	char *name;
-	unsigned len = strlen(c->name);
-	if (NULL == c->parent) {
-		/* allocate enough for the name, child names, and '\0' */
-		name = malloc(len + extra + 1);
-		strcpy(name, c->name);
-	} else {
-		/* parent's extra must include both the space and name */
-		name = __command_name(c->parent, delim, 1 + len + extra);
-		char dstr[2] = { delim, 0 };
-		strcat(name, dstr);
-		strcat(name, c->name);
-	}
-	return name;
-}
-
-char *command_name(struct command *c, char delim)
-{
-	return __command_name(c, delim, 0);
-}
-
-static bool command_can_run(struct command_context *cmd_ctx, struct command *c)
-{
-	return c->mode == COMMAND_ANY || c->mode == cmd_ctx->mode;
-}
-
-static int run_command(struct command_context *context,
-	struct command *c, const char *words[], unsigned num_words)
-{
-	if (!command_can_run(context, c)) {
-		/* Many commands may be run only before/after 'init' */
-		const char *when;
-		switch (c->mode) {
-			case COMMAND_CONFIG:
-				when = "before";
-				break;
-			case COMMAND_EXEC:
-				when = "after";
-				break;
-			/* handle the impossible with humor; it guarantees a bug report! */
-			default:
-				when = "if Cthulhu is summoned by";
-				break;
-		}
-		LOG_ERROR("The '%s' command must be used %s 'init'.",
-			c->name, when);
-		return ERROR_FAIL;
-	}
-
-	struct command_invocation cmd = {
-		.ctx = context,
-		.current = c,
-		.name = c->name,
-		.argc = num_words - 1,
-		.argv = words + 1,
-	};
-	int retval = c->handler(&cmd);
-	if (retval == ERROR_COMMAND_SYNTAX_ERROR) {
-		/* Print help for command */
-		char *full_name = command_name(c, ' ');
-		if (NULL != full_name) {
-			command_run_linef(context, "usage %s", full_name);
-			free(full_name);
-		} else
-			retval = -ENOMEM;
-	} else if (retval == ERROR_COMMAND_CLOSE_CONNECTION) {
-		/* just fall through for a shutdown request */
-	} else if (retval != ERROR_OK) {
-		/* we do not print out an error message because the command *should*
-		 * have printed out an error
-		 */
-		LOG_DEBUG("Command failed with error code %d", retval);
-	}
-
-	return retval;
-}
-
-int command_run_line(struct command_context *context, char *line)
-{
-	/* all the parent commands have been registered with the interpreter
-	 * so, can just evaluate the line as a script and check for
-	 * results
-	 */
-	/* run the line thru a script engine */
-	int retval = ERROR_FAIL;
-	int retcode;
-	/* Beware! This code needs to be reentrant. It is also possible
-	 * for OpenOCD commands to be invoked directly from Tcl. This would
-	 * happen when the Jim Tcl interpreter is provided by eCos for
-	 * instance.
-	 */
-	Jim_Interp *interp = context->interp;
-	Jim_DeleteAssocData(interp, "context");
-	retcode = Jim_SetAssocData(interp, "context", NULL, context);
-	if (retcode == JIM_OK) {
-		/* associated the return value */
-		Jim_DeleteAssocData(interp, "retval");
-		retcode = Jim_SetAssocData(interp, "retval", NULL, &retval);
-		if (retcode == JIM_OK) {
-			retcode = Jim_Eval_Named(interp, line, 0, 0);
-
-			Jim_DeleteAssocData(interp, "retval");
-		}
-		Jim_DeleteAssocData(interp, "context");
-	}
-	if (retcode == JIM_OK) {
-		const char *result;
-		int reslen;
-
-		result = Jim_GetString(Jim_GetResult(interp), &reslen);
-		if (reslen > 0) {
-			int i;
-			char buff[256 + 1];
-			for (i = 0; i < reslen; i += 256) {
-				int chunk;
-				chunk = reslen - i;
-				if (chunk > 256)
-					chunk = 256;
-				strncpy(buff, result + i, chunk);
-				buff[chunk] = 0;
-				LOG_USER_N("%s", buff);
-			}
-			LOG_USER_N("\n");
-		}
-		retval = ERROR_OK;
-	} else if (retcode == JIM_EXIT) {
-		/* ignore.
-		 * exit(Jim_GetExitCode(interp)); */
-	} else if (retcode == ERROR_COMMAND_CLOSE_CONNECTION) {
-		return retcode;
-	} else {
-		Jim_MakeErrorMessage(interp);
-		LOG_USER("%s", Jim_GetString(Jim_GetResult(interp), NULL));
-
-		if (retval == ERROR_OK) {
-			/* It wasn't a low level OpenOCD command that failed */
-			return ERROR_FAIL;
-		}
-		return retval;
-	}
-
-	return retval;
-}
-
-int command_run_linef(struct command_context *context, const char *format, ...)
-{
-	int retval = ERROR_FAIL;
-	char *string;
-	va_list ap;
-	va_start(ap, format);
-	string = alloc_vprintf(format, ap);
-	if (string != NULL) {
-		retval = command_run_line(context, string);
-		free(string);
-	}
-	va_end(ap);
-	return retval;
-}
-
-void command_set_output_handler(struct command_context *context,
-	command_output_handler_t output_handler, void *priv)
-{
-	context->output_handler = output_handler;
-	context->output_handler_priv = priv;
-}
-
-struct command_context *copy_command_context(struct command_context *context)
-{
-	struct command_context *copy_context = malloc(sizeof(struct command_context));
-
-	*copy_context = *context;
-
-	return copy_context;
-}
-
-void command_done(struct command_context *cmd_ctx)
-{
-	if (NULL == cmd_ctx)
-		return;
-
-	free(cmd_ctx);
-}
-
-/* find full path to file */
-static int jim_find(Jim_Interp *interp, int argc, Jim_Obj *const *argv)
-{
-	if (argc != 2)
-		return JIM_ERR;
-	const char *file = Jim_GetString(argv[1], NULL);
-	char *full_path = find_file(file);
-	if (full_path == NULL)
-		return JIM_ERR;
-	Jim_Obj *result = Jim_NewStringObj(interp, full_path, strlen(full_path));
-	free(full_path);
-
-	Jim_SetResult(interp, result);
-	return JIM_OK;
-}
-
-COMMAND_HANDLER(jim_echo)
-{
-	if (CMD_ARGC == 2 && !strcmp(CMD_ARGV[0], "-n")) {
-		LOG_USER_N("%s", CMD_ARGV[1]);
-		return JIM_OK;
-	}
-	if (CMD_ARGC != 1)
-		return JIM_ERR;
-	LOG_USER("%s", CMD_ARGV[0]);
-	return JIM_OK;
-}
-
-/* Capture progress output and return as tcl return value. If the
- * progress output was empty, return tcl return value.
- */
-static int jim_capture(Jim_Interp *interp, int argc, Jim_Obj *const *argv)
-{
-	if (argc != 2)
-		return JIM_ERR;
-
-	struct log_capture_state *state = command_log_capture_start(interp);
-
-	/* disable polling during capture. This avoids capturing output
-	 * from polling.
-	 *
-	 * This is necessary in order to avoid accidentally getting a non-empty
-	 * string for tcl fn's.
-	 */
-	bool save_poll = jtag_poll_get_enabled();
-
-	jtag_poll_set_enabled(false);
-
-	const char *str = Jim_GetString(argv[1], NULL);
-	int retcode = Jim_Eval_Named(interp, str, __THIS__FILE__, __LINE__);
-
-	jtag_poll_set_enabled(save_poll);
-
-	command_log_capture_finish(state);
-
-	return retcode;
-}
-
-static COMMAND_HELPER(command_help_find, struct command *head,
-	struct command **out)
-{
-	if (0 == CMD_ARGC)
-		return ERROR_COMMAND_SYNTAX_ERROR;
-	*out = command_find(head, CMD_ARGV[0]);
-	if (NULL == *out && strncmp(CMD_ARGV[0], "ocd_", 4) == 0)
-		*out = command_find(head, CMD_ARGV[0] + 4);
-	if (NULL == *out)
-		return ERROR_COMMAND_SYNTAX_ERROR;
-	if (--CMD_ARGC == 0)
-		return ERROR_OK;
-	CMD_ARGV++;
-	return CALL_COMMAND_HANDLER(command_help_find, (*out)->children, out);
-}
-
-static COMMAND_HELPER(command_help_show, struct command *c, unsigned n,
-	bool show_help, const char *cmd_match);
-
-static COMMAND_HELPER(command_help_show_list, struct command *head, unsigned n,
-	bool show_help, const char *cmd_match)
-{
-	for (struct command *c = head; NULL != c; c = c->next)
-		CALL_COMMAND_HANDLER(command_help_show, c, n, show_help, cmd_match);
-	return ERROR_OK;
-}
-
-#define HELP_LINE_WIDTH(_n) (int)(76 - (2 * _n))
-
-static void command_help_show_indent(unsigned n)
-{
-	for (unsigned i = 0; i < n; i++)
-		LOG_USER_N("  ");
-}
-static void command_help_show_wrap(const char *str, unsigned n, unsigned n2)
-{
-	const char *cp = str, *last = str;
-	while (*cp) {
-		const char *next = last;
-		do {
-			cp = next;
-			do {
-				next++;
-			} while (*next != ' ' && *next != '\t' && *next != '\0');
-		} while ((next - last < HELP_LINE_WIDTH(n)) && *next != '\0');
-		if (next - last < HELP_LINE_WIDTH(n))
-			cp = next;
-		command_help_show_indent(n);
-		LOG_USER("%.*s", (int)(cp - last), last);
-		last = cp + 1;
-		n = n2;
-	}
-}
-
-static COMMAND_HELPER(command_help_show, struct command *c, unsigned n,
-	bool show_help, const char *cmd_match)
-{
-	char *cmd_name = command_name(c, ' ');
-	if (NULL == cmd_name)
-		return -ENOMEM;
-
-	/* If the match string occurs anywhere, we print out
-	 * stuff for this command. */
-	bool is_match = (strstr(cmd_name, cmd_match) != NULL) ||
-		((c->usage != NULL) && (strstr(c->usage, cmd_match) != NULL)) ||
-		((c->help != NULL) && (strstr(c->help, cmd_match) != NULL));
-
-	if (is_match) {
-		command_help_show_indent(n);
-		LOG_USER_N("%s", cmd_name);
-	}
-	free(cmd_name);
-
-	if (is_match) {
-		if (c->usage && strlen(c->usage) > 0) {
-			LOG_USER_N(" ");
-			command_help_show_wrap(c->usage, 0, n + 5);
-		} else
-			LOG_USER_N("\n");
-	}
-
-	if (is_match && show_help) {
-		char *msg;
-
-		/* Normal commands are runtime-only; highlight exceptions */
-		if (c->mode != COMMAND_EXEC) {
-			const char *stage_msg = "";
-
-			switch (c->mode) {
-				case COMMAND_CONFIG:
-					stage_msg = " (configuration command)";
-					break;
-				case COMMAND_ANY:
-					stage_msg = " (command valid any time)";
-					break;
-				default:
-					stage_msg = " (?mode error?)";
-					break;
-			}
-			msg = alloc_printf("%s%s", c->help ? : "", stage_msg);
-		} else
-			msg = alloc_printf("%s", c->help ? : "");
-
-		if (NULL != msg) {
-			command_help_show_wrap(msg, n + 3, n + 3);
-			free(msg);
-		} else
-			return -ENOMEM;
-	}
-
-	if (++n > 5) {
-		LOG_ERROR("command recursion exceeded");
-		return ERROR_FAIL;
-	}
-
-	return CALL_COMMAND_HANDLER(command_help_show_list,
-		c->children, n, show_help, cmd_match);
-}
-
-COMMAND_HANDLER(handle_help_command)
-{
-	bool full = strcmp(CMD_NAME, "help") == 0;
-	int retval;
-	struct command *c = CMD_CTX->commands;
-	char *cmd_match = NULL;
-
-	if (CMD_ARGC == 0)
-		cmd_match = "";
-	else if (CMD_ARGC >= 1) {
-		unsigned i;
-
-		for (i = 0; i < CMD_ARGC; ++i) {
-			if (NULL != cmd_match) {
-				char *prev = cmd_match;
-
-				cmd_match = alloc_printf("%s %s", cmd_match, CMD_ARGV[i]);
-				free(prev);
-				if (NULL == cmd_match) {
-					LOG_ERROR("unable to build search string");
-					return -ENOMEM;
-				}
-			} else {
-				cmd_match = alloc_printf("%s", CMD_ARGV[i]);
-				if (NULL == cmd_match) {
-					LOG_ERROR("unable to build search string");
-					return -ENOMEM;
-				}
-			}
-		}
-	} else
-		return ERROR_COMMAND_SYNTAX_ERROR;
-
-	retval = CALL_COMMAND_HANDLER(command_help_show_list,
-			c, 0, full, cmd_match);
-
-	if (CMD_ARGC >= 1)
-		free(cmd_match);
-	return retval;
-}
-
-static int command_unknown_find(unsigned argc, Jim_Obj *const *argv,
-	struct command *head, struct command **out, bool top_level)
-{
-	if (0 == argc)
-		return argc;
-	const char *cmd_name = Jim_GetString(argv[0], NULL);
-	struct command *c = command_find(head, cmd_name);
-	if (NULL == c && top_level && strncmp(cmd_name, "ocd_", 4) == 0)
-		c = command_find(head, cmd_name + 4);
-	if (NULL == c)
-		return argc;
-	*out = c;
-	return command_unknown_find(--argc, ++argv, (*out)->children, out, false);
-}
-
-static int command_unknown(Jim_Interp *interp, int argc, Jim_Obj *const *argv)
-{
-	const char *cmd_name = Jim_GetString(argv[0], NULL);
-	if (strcmp(cmd_name, "unknown") == 0) {
-		if (argc == 1)
-			return JIM_OK;
-		argc--;
-		argv++;
-	}
-	script_debug(interp, cmd_name, argc, argv);
-
-	struct command_context *cmd_ctx = current_command_context(interp);
-	struct command *c = cmd_ctx->commands;
-	int remaining = command_unknown_find(argc, argv, c, &c, true);
-	/* if nothing could be consumed, then it's really an unknown command */
-	if (remaining == argc) {
-		const char *cmd = Jim_GetString(argv[0], NULL);
-		LOG_ERROR("Unknown command:\n  %s", cmd);
-		return JIM_OK;
-	}
-
-	bool found = true;
-	Jim_Obj *const *start;
-	unsigned count;
-	if (c->handler || c->jim_handler) {
-		/* include the command name in the list */
-		count = remaining + 1;
-		start = argv + (argc - remaining - 1);
-	} else {
-		c = command_find(cmd_ctx->commands, "usage");
-		if (NULL == c) {
-			LOG_ERROR("unknown command, but usage is missing too");
-			return JIM_ERR;
-		}
-		count = argc - remaining;
-		start = argv;
-		found = false;
-	}
-	/* pass the command through to the intended handler */
-	if (c->jim_handler) {
-		interp->cmdPrivData = c->jim_handler_data;
-		return (*c->jim_handler)(interp, count, start);
-	}
-
-	return script_command_run(interp, count, start, c, found);
-}
-
-static int jim_command_mode(Jim_Interp *interp, int argc, Jim_Obj *const *argv)
-{
-	struct command_context *cmd_ctx = current_command_context(interp);
-	enum command_mode mode;
-
-	if (argc > 1) {
-		struct command *c = cmd_ctx->commands;
-		int remaining = command_unknown_find(argc - 1, argv + 1, c, &c, true);
-		/* if nothing could be consumed, then it's an unknown command */
-		if (remaining == argc - 1) {
-			Jim_SetResultString(interp, "unknown", -1);
-			return JIM_OK;
-		}
-		mode = c->mode;
-	} else
-		mode = cmd_ctx->mode;
-
-	const char *mode_str;
-	switch (mode) {
-		case COMMAND_ANY:
-			mode_str = "any";
-			break;
-		case COMMAND_CONFIG:
-			mode_str = "config";
-			break;
-		case COMMAND_EXEC:
-			mode_str = "exec";
-			break;
-		default:
-			mode_str = "unknown";
-			break;
-	}
-	Jim_SetResultString(interp, mode_str, -1);
-	return JIM_OK;
-}
-
-static int jim_command_type(Jim_Interp *interp, int argc, Jim_Obj *const *argv)
-{
-	if (1 == argc)
-		return JIM_ERR;
-
-	struct command_context *cmd_ctx = current_command_context(interp);
-	struct command *c = cmd_ctx->commands;
-	int remaining = command_unknown_find(argc - 1, argv + 1, c, &c, true);
-	/* if nothing could be consumed, then it's an unknown command */
-	if (remaining == argc - 1) {
-		Jim_SetResultString(interp, "unknown", -1);
-		return JIM_OK;
-	}
-
-	if (c->jim_handler)
-		Jim_SetResultString(interp, "native", -1);
-	else if (c->handler)
-		Jim_SetResultString(interp, "simple", -1);
-	else if (remaining == 0)
-		Jim_SetResultString(interp, "group", -1);
-	else
-		Jim_SetResultString(interp, "unknown", -1);
-
-	return JIM_OK;
-}
-
-int help_add_command(struct command_context *cmd_ctx, struct command *parent,
-	const char *cmd_name, const char *help_text, const char *usage)
-{
-	struct command **head = command_list_for_parent(cmd_ctx, parent);
-	struct command *nc = command_find(*head, cmd_name);
-	if (NULL == nc) {
-		/* add a new command with help text */
-		struct command_registration cr = {
-			.name = cmd_name,
-			.mode = COMMAND_ANY,
-			.help = help_text,
-			.usage = usage,
-		};
-		nc = register_command(cmd_ctx, parent, &cr);
-		if (NULL == nc) {
-			LOG_ERROR("failed to add '%s' help text", cmd_name);
-			return ERROR_FAIL;
-		}
-		LOG_DEBUG("added '%s' help text", cmd_name);
-		return ERROR_OK;
-	}
-	if (help_text) {
-		bool replaced = false;
-		if (nc->help) {
-			free(nc->help);
-			replaced = true;
-		}
-		nc->help = strdup(help_text);
-		if (replaced)
-			LOG_INFO("replaced existing '%s' help", cmd_name);
-		else
-			LOG_DEBUG("added '%s' help text", cmd_name);
-	}
-	if (usage) {
-		bool replaced = false;
-		if (nc->usage) {
-			free(nc->usage);
-			replaced = true;
-		}
-		nc->usage = strdup(usage);
-		if (replaced)
-			LOG_INFO("replaced existing '%s' usage", cmd_name);
-		else
-			LOG_DEBUG("added '%s' usage text", cmd_name);
-	}
-	return ERROR_OK;
-}
-
-COMMAND_HANDLER(handle_help_add_command)
-{
-	if (CMD_ARGC < 2) {
-		LOG_ERROR("%s: insufficient arguments", CMD_NAME);
-		return ERROR_COMMAND_SYNTAX_ERROR;
-	}
-
-	/* save help text and remove it from argument list */
-	const char *str = CMD_ARGV[--CMD_ARGC];
-	const char *help = !strcmp(CMD_NAME, "add_help_text") ? str : NULL;
-	const char *usage = !strcmp(CMD_NAME, "add_usage_text") ? str : NULL;
-	if (!help && !usage) {
-		LOG_ERROR("command name '%s' is unknown", CMD_NAME);
-		return ERROR_COMMAND_SYNTAX_ERROR;
-	}
-	/* likewise for the leaf command name */
-	const char *cmd_name = CMD_ARGV[--CMD_ARGC];
-
-	struct command *c = NULL;
-	if (CMD_ARGC > 0) {
-		c = CMD_CTX->commands;
-		int retval = CALL_COMMAND_HANDLER(command_help_find, c, &c);
-		if (ERROR_OK != retval)
-			return retval;
-	}
-	return help_add_command(CMD_CTX, c, cmd_name, help, usage);
-}
-
-/* sleep command sleeps for <n> milliseconds
- * this is useful in target startup scripts
- */
-COMMAND_HANDLER(handle_sleep_command)
-{
-	bool busy = false;
-	if (CMD_ARGC == 2) {
-		if (strcmp(CMD_ARGV[1], "busy") == 0)
-			busy = true;
-		else
-			return ERROR_COMMAND_SYNTAX_ERROR;
-	} else if (CMD_ARGC < 1 || CMD_ARGC > 2)
-		return ERROR_COMMAND_SYNTAX_ERROR;
-
-	unsigned long duration = 0;
-	int retval = parse_ulong(CMD_ARGV[0], &duration);
-	if (ERROR_OK != retval)
-		return retval;
-
-	if (!busy) {
-		long long then = timeval_ms();
-		while (timeval_ms() - then < (long long)duration) {
-			target_call_timer_callbacks_now();
-			usleep(1000);
-		}
-	} else
-		busy_sleep(duration);
-
-	return ERROR_OK;
-}
-
-static const struct command_registration command_subcommand_handlers[] = {
-	{
-		.name = "mode",
-		.mode = COMMAND_ANY,
-		.jim_handler = jim_command_mode,
-		.usage = "[command_name ...]",
-		.help = "Returns the command modes allowed by a  command:"
-			"'any', 'config', or 'exec'.  If no command is"
-			"specified, returns the current command mode.  "
-			"Returns 'unknown' if an unknown command is given. "
-			"Command can be multiple tokens.",
-	},
-	{
-		.name = "type",
-		.mode = COMMAND_ANY,
-		.jim_handler = jim_command_type,
-		.usage = "command_name [...]",
-		.help = "Returns the type of built-in command:"
-			"'native', 'simple', 'group', or 'unknown'. "
-			"Command can be multiple tokens.",
-	},
-	COMMAND_REGISTRATION_DONE
-};
-
-static const struct command_registration command_builtin_handlers[] = {
-	{
-		.name = "echo",
-		.handler = jim_echo,
-		.mode = COMMAND_ANY,
-		.help = "Logs a message at \"user\" priority. "
-			"Output message to stdout. "
-			"Option \"-n\" suppresses trailing newline",
-		.usage = "[-n] string",
-	},
-	{
-		.name = "add_help_text",
-		.handler = handle_help_add_command,
-		.mode = COMMAND_ANY,
-		.help = "Add new command help text; "
-			"Command can be multiple tokens.",
-		.usage = "command_name helptext_string",
-	},
-	{
-		.name = "add_usage_text",
-		.handler = handle_help_add_command,
-		.mode = COMMAND_ANY,
-		.help = "Add new command usage text; "
-			"command can be multiple tokens.",
-		.usage = "command_name usage_string",
-	},
-	{
-		.name = "sleep",
-		.handler = handle_sleep_command,
-		.mode = COMMAND_ANY,
-		.help = "Sleep for specified number of milliseconds.  "
-			"\"busy\" will busy wait instead (avoid this).",
-		.usage = "milliseconds ['busy']",
-	},
-	{
-		.name = "help",
-		.handler = handle_help_command,
-		.mode = COMMAND_ANY,
-		.help = "Show full command help; "
-			"command can be multiple tokens.",
-		.usage = "[command_name]",
-	},
-	{
-		.name = "usage",
-		.handler = handle_help_command,
-		.mode = COMMAND_ANY,
-		.help = "Show basic command usage; "
-			"command can be multiple tokens.",
-		.usage = "[command_name]",
-	},
-	{
-		.name = "command",
-		.mode = COMMAND_ANY,
-		.help = "core command group (introspection)",
-		.chain = command_subcommand_handlers,
-	},
-	COMMAND_REGISTRATION_DONE
-};
-
-struct command_context *command_init(const char *startup_tcl, Jim_Interp *interp)
-{
-	struct command_context *context = malloc(sizeof(struct command_context));
-	const char *HostOs;
-
-	context->mode = COMMAND_EXEC;
-	context->commands = NULL;
-	context->current_target = 0;
-	context->output_handler = NULL;
-	context->output_handler_priv = NULL;
-
-	/* Create a jim interpreter if we were not handed one */
-	if (interp == NULL) {
-		/* Create an interpreter */
-		interp = Jim_CreateInterp();
-		/* Add all the Jim core commands */
-		Jim_RegisterCoreCommands(interp);
-		Jim_InitStaticExtensions(interp);
-	}
-
-	context->interp = interp;
-
-	/* Stick to lowercase for HostOS strings. */
-#if defined(_MSC_VER)
-	/* WinXX - is generic, the forward
-	 * looking problem is this:
-	 *
-	 *   "win32" or "win64"
-	 *
-	 * "winxx" is generic.
-	 */
-	HostOs = "winxx";
-#elif defined(__linux__)
-	HostOs = "linux";
-#elif defined(__APPLE__) || defined(__DARWIN__)
-	HostOs = "darwin";
-#elif defined(__CYGWIN__)
-	HostOs = "cygwin";
-#elif defined(__MINGW32__)
-	HostOs = "mingw32";
-#elif defined(__ECOS)
-	HostOs = "ecos";
-#elif defined(__FreeBSD__)
-	HostOs = "freebsd";
-#elif defined(__NetBSD__)
-	HostOs = "netbsd";
-#elif defined(__OpenBSD__)
-	HostOs = "openbsd";
-#else
-#warning "Unrecognized host OS..."
-	HostOs = "other";
-#endif
-	Jim_SetGlobalVariableStr(interp, "ocd_HOSTOS",
-		Jim_NewStringObj(interp, HostOs, strlen(HostOs)));
-
-	Jim_CreateCommand(interp, "ocd_find", jim_find, NULL, NULL);
-	Jim_CreateCommand(interp, "capture", jim_capture, NULL, NULL);
-
-	register_commands(context, NULL, command_builtin_handlers);
-
-	Jim_SetAssocData(interp, "context", NULL, context);
-	if (Jim_Eval_Named(interp, startup_tcl, "embedded:startup.tcl", 1) == JIM_ERR) {
-		LOG_ERROR("Failed to run startup.tcl (embedded into OpenOCD)");
-		Jim_MakeErrorMessage(interp);
-		LOG_USER_N("%s", Jim_GetString(Jim_GetResult(interp), NULL));
-		exit(-1);
-	}
-	Jim_DeleteAssocData(interp, "context");
-
-	return context;
-}
-
-int command_context_mode(struct command_context *cmd_ctx, enum command_mode mode)
-{
-	if (!cmd_ctx)
-		return ERROR_COMMAND_SYNTAX_ERROR;
-
-	cmd_ctx->mode = mode;
-	return ERROR_OK;
-}
-
-void process_jim_events(struct command_context *cmd_ctx)
-{
-	static int recursion;
-	if (recursion)
-		return;
-
-	recursion++;
-	Jim_ProcessEvents(cmd_ctx->interp, JIM_ALL_EVENTS | JIM_DONT_WAIT);
-	recursion--;
-}
-
-#define DEFINE_PARSE_NUM_TYPE(name, type, func, min, max) \
-	int parse ## name(const char *str, type * ul) \
-	{ \
-		if (!*str) { \
-			LOG_ERROR("Invalid command argument"); \
-			return ERROR_COMMAND_ARGUMENT_INVALID; \
-		} \
-		char *end; \
-		*ul = func(str, &end, 0); \
-		if (*end) { \
-			LOG_ERROR("Invalid command argument"); \
-			return ERROR_COMMAND_ARGUMENT_INVALID; \
-		} \
-		if ((max == *ul) && (ERANGE == errno)) { \
-			LOG_ERROR("Argument overflow");	\
-			return ERROR_COMMAND_ARGUMENT_OVERFLOW;	\
-		} \
-		if (min && (min == *ul) && (ERANGE == errno)) { \
-			LOG_ERROR("Argument underflow"); \
-			return ERROR_COMMAND_ARGUMENT_UNDERFLOW; \
-		} \
-		return ERROR_OK; \
-	}
-DEFINE_PARSE_NUM_TYPE(_ulong, unsigned long, strtoul, 0, ULONG_MAX)
-DEFINE_PARSE_NUM_TYPE(_ullong, unsigned long long, strtoull, 0, ULLONG_MAX)
-DEFINE_PARSE_NUM_TYPE(_long, long, strtol, LONG_MIN, LONG_MAX)
-DEFINE_PARSE_NUM_TYPE(_llong, long long, strtoll, LLONG_MIN, LLONG_MAX)
-
-#define DEFINE_PARSE_WRAPPER(name, type, min, max, functype, funcname) \
-	int parse ## name(const char *str, type * ul) \
-	{ \
-		functype n; \
-		int retval = parse ## funcname(str, &n); \
-		if (ERROR_OK != retval)	\
-			return retval; \
-		if (n > max) \
-			return ERROR_COMMAND_ARGUMENT_OVERFLOW;	\
-		if (min) \
-			return ERROR_COMMAND_ARGUMENT_UNDERFLOW; \
-		*ul = n; \
-		return ERROR_OK; \
-	}
-
-#define DEFINE_PARSE_ULONGLONG(name, type, min, max) \
-	DEFINE_PARSE_WRAPPER(name, type, min, max, unsigned long long, _ullong)
-DEFINE_PARSE_ULONGLONG(_uint, unsigned, 0, UINT_MAX)
-DEFINE_PARSE_ULONGLONG(_u64,  uint64_t, 0, UINT64_MAX)
-DEFINE_PARSE_ULONGLONG(_u32,  uint32_t, 0, UINT32_MAX)
-DEFINE_PARSE_ULONGLONG(_u16,  uint16_t, 0, UINT16_MAX)
-DEFINE_PARSE_ULONGLONG(_u8,   uint8_t,  0, UINT8_MAX)
-
-#define DEFINE_PARSE_LONGLONG(name, type, min, max) \
-	DEFINE_PARSE_WRAPPER(name, type, min, max, long long, _llong)
-DEFINE_PARSE_LONGLONG(_int, int,     n < INT_MIN,   INT_MAX)
-DEFINE_PARSE_LONGLONG(_s64, int64_t, n < INT64_MIN, INT64_MAX)
-DEFINE_PARSE_LONGLONG(_s32, int32_t, n < INT32_MIN, INT32_MAX)
-DEFINE_PARSE_LONGLONG(_s16, int16_t, n < INT16_MIN, INT16_MAX)
-DEFINE_PARSE_LONGLONG(_s8,  int8_t,  n < INT8_MIN,  INT8_MAX)
-
-static int command_parse_bool(const char *in, bool *out,
-	const char *on, const char *off)
-{
-	if (strcasecmp(in, on) == 0)
-		*out = true;
-	else if (strcasecmp(in, off) == 0)
-		*out = false;
-	else
-		return ERROR_COMMAND_SYNTAX_ERROR;
-	return ERROR_OK;
-}
-
-int command_parse_bool_arg(const char *in, bool *out)
-{
-	if (command_parse_bool(in, out, "on", "off") == ERROR_OK)
-		return ERROR_OK;
-	if (command_parse_bool(in, out, "enable", "disable") == ERROR_OK)
-		return ERROR_OK;
-	if (command_parse_bool(in, out, "true", "false") == ERROR_OK)
-		return ERROR_OK;
-	if (command_parse_bool(in, out, "yes", "no") == ERROR_OK)
-		return ERROR_OK;
-	if (command_parse_bool(in, out, "1", "0") == ERROR_OK)
-		return ERROR_OK;
-	return ERROR_COMMAND_SYNTAX_ERROR;
-}
-
-COMMAND_HELPER(handle_command_parse_bool, bool *out, const char *label)
-{
-	switch (CMD_ARGC) {
-		case 1: {
-			const char *in = CMD_ARGV[0];
-			if (command_parse_bool_arg(in, out) != ERROR_OK) {
-				LOG_ERROR("%s: argument '%s' is not valid", CMD_NAME, in);
-				return ERROR_COMMAND_SYNTAX_ERROR;
-			}
-			/* fall through */
-		}
-		case 0:
-			LOG_INFO("%s is %s", label, *out ? "enabled" : "disabled");
-			break;
-		default:
-			return ERROR_COMMAND_SYNTAX_ERROR;
-	}
-	return ERROR_OK;
-}

http://git-wip-us.apache.org/repos/asf/incubator-mynewt-site/blob/69f466b5/docs/os/tutorials/downloads/openocd-code-89bf96ffe6ac66c80407af8383b9d5adc0dc35f4/src/helper/command.h
----------------------------------------------------------------------
diff --git a/docs/os/tutorials/downloads/openocd-code-89bf96ffe6ac66c80407af8383b9d5adc0dc35f4/src/helper/command.h b/docs/os/tutorials/downloads/openocd-code-89bf96ffe6ac66c80407af8383b9d5adc0dc35f4/src/helper/command.h
deleted file mode 100755
index 0eda5b5..0000000
--- a/docs/os/tutorials/downloads/openocd-code-89bf96ffe6ac66c80407af8383b9d5adc0dc35f4/src/helper/command.h
+++ /dev/null
@@ -1,420 +0,0 @@
-/***************************************************************************
- *   Copyright (C) 2005 by Dominic Rath                                    *
- *   Dominic.Rath@gmx.de                                                   *
- *                                                                         *
- *   Copyright (C) 2007,2008 �yvind Harboe                                 *
- *   oyvind.harboe@zylin.com                                               *
- *                                                                         *
- *   This program is free software; you can redistribute it and/or modify  *
- *   it under the terms of the GNU General Public License as published by  *
- *   the Free Software Foundation; either version 2 of the License, or     *
- *   (at your option) any later version.                                   *
- *                                                                         *
- *   This program is distributed in the hope that it will be useful,       *
- *   but WITHOUT ANY WARRANTY; without even the implied warranty of        *
- *   MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE.  See the         *
- *   GNU General Public License for more details.                          *
- *                                                                         *
- *   You should have received a copy of the GNU General Public License     *
- *   along with this program; if not, write to the                         *
- *   Free Software Foundation, Inc.,                                       *
- *   51 Franklin Street, Fifth Floor, Boston, MA 02110-1301 USA.           *
- ***************************************************************************/
-
-#ifndef COMMAND_H
-#define COMMAND_H
-
-#include <jim-nvp.h>
-
-/* To achieve C99 printf compatibility in MinGW, gnu_printf should be
- * used for __attribute__((format( ... ))), with GCC v4.4 or later
- */
-#if (defined(IS_MINGW) && (((__GNUC__ << 16) + __GNUC_MINOR__) >= 0x00040004))
-#define PRINTF_ATTRIBUTE_FORMAT gnu_printf
-#else
-#define PRINTF_ATTRIBUTE_FORMAT printf
-#endif
-
-enum command_mode {
-	COMMAND_EXEC,
-	COMMAND_CONFIG,
-	COMMAND_ANY,
-};
-
-struct command_context;
-
-/** The type signature for command context's output handler. */
-typedef int (*command_output_handler_t)(struct command_context *context,
-		const char *line);
-
-struct command_context {
-	Jim_Interp *interp;
-	enum command_mode mode;
-	struct command *commands;
-	int current_target;
-	command_output_handler_t output_handler;
-	void *output_handler_priv;
-};
-
-struct command;
-
-/**
- * When run_command is called, a new instance will be created on the
- * stack, filled with the proper values, and passed by reference to the
- * required COMMAND_HANDLER routine.
- */
-struct command_invocation {
-	struct command_context *ctx;
-	struct command *current;
-	const char *name;
-	unsigned argc;
-	const char **argv;
-};
-
-/**
- * Command handlers may be defined with more parameters than the base
- * set provided by command.c.  This macro uses C99 magic to allow
- * defining all such derivative types using this macro.
- */
-#define __COMMAND_HANDLER(name, extra ...) \
-		int name(struct command_invocation *cmd, ## extra)
-
-/**
- * Use this to macro to call a command helper (or a nested handler).
- * It provides command handler authors protection against reordering or
- * removal of unused parameters.
- *
- * @b Note: This macro uses lexical capture to provide some arguments.
- * As a result, this macro should be used @b only within functions
- * defined by the COMMAND_HANDLER or COMMAND_HELPER macros.  Those
- * macros provide the expected lexical context captured by this macro.
- * Furthermore, it should be used only from the top-level of handler or
- * helper function, or care must be taken to avoid redefining the same
- * variables in intervening scope(s) by accident.
- */
-#define CALL_COMMAND_HANDLER(name, extra ...) \
-		name(cmd, ## extra)
-
-/**
- * Always use this macro to define new command handler functions.
- * It ensures the parameters are ordered, typed, and named properly, so
- * they be can be used by other macros (e.g. COMMAND_PARSE_NUMBER).
- * All command handler functions must be defined as static in scope.
- */
-#define COMMAND_HANDLER(name) \
-		static __COMMAND_HANDLER(name)
-
-/**
- * Similar to COMMAND_HANDLER, except some parameters are expected.
- * A helper is globally-scoped because it may be shared between several
- * source files (e.g. the s3c24xx device command helper).
- */
-#define COMMAND_HELPER(name, extra ...) __COMMAND_HANDLER(name, extra)
-
-/**
- * Use this macro to access the context of the command being handled,
- * rather than accessing the variable directly.  It may be moved.
- */
-#define CMD_CTX (cmd->ctx)
-/**
- * Use this macro to access the number of arguments for the command being
- * handled, rather than accessing the variable directly.  It may be moved.
- */
-#define CMD_ARGC (cmd->argc)
-/**
- * Use this macro to access the arguments for the command being handled,
- * rather than accessing the variable directly.  It may be moved.
- */
-#define CMD_ARGV (cmd->argv)
-/**
- * Use this macro to access the name of the command being handled,
- * rather than accessing the variable directly.  It may be moved.
- */
-#define CMD_NAME (cmd->name)
-/**
- * Use this macro to access the current command being handled,
- * rather than accessing the variable directly.  It may be moved.
- */
-#define CMD_CURRENT (cmd->current)
-/**
- * Use this macro to access the invoked command handler's data pointer,
- * rather than accessing the variable directly.  It may be moved.
- */
-#define CMD_DATA (CMD_CURRENT->jim_handler_data)
-
-/**
- * The type signature for command handling functions.  They are
- * usually registered as part of command_registration, providing
- * a high-level means for executing a command.
- *
- * If the command fails, it *MUST* return a value != ERROR_OK
- * (many commands break this rule, patches welcome!)
- *
- * This is *especially* important for commands such as writing
- * to flash or verifying memory. The reason is that those commands
- * can be used by programs to determine if the operation succeded
- * or not. If the operation failed, then a program can try
- * an alternative approach.
- *
- * Returning ERROR_COMMAND_SYNTAX_ERROR will have the effect of
- * printing out the syntax of the command.
- */
-typedef __COMMAND_HANDLER((*command_handler_t));
-
-struct command {
-	char *name;
-	char *help;
-	char *usage;
-	struct command *parent;
-	struct command *children;
-	command_handler_t handler;
-	Jim_CmdProc *jim_handler;
-	void *jim_handler_data;
-	enum command_mode mode;
-	struct command *next;
-};
-
-/**
- * @param c The command to be named.
- * @param delim The character to place between command names.
- * @returns A malloc'd string containing the full command name,
- * which may include one or more ancestor components.  Multiple names
- * are separated by single spaces.  The caller must free() the string
- * when done with it.
- */
-char *command_name(struct command *c, char delim);
-
-/*
- * Commands should be registered by filling in one or more of these
- * structures and passing them to register_command().
- *
- * A conventioal format should be used for help strings, to provide both
- * usage and basic information:
- * @code
- * "@<options@> ... - some explanation text"
- * @endcode
- *
- * @param name The name of the command to register, which must not have
- * been registered previously in the intended context.
- * @param handler The callback function that will be called.  If NULL,
- * then the command serves as a placeholder for its children or a script.
- * @param mode The command mode(s) in which this command may be run.
- * @param help The help text that will be displayed to the user.
- */
-struct command_registration {
-	const char *name;
-	command_handler_t handler;
-	Jim_CmdProc *jim_handler;
-	void *jim_handler_data;
-	enum command_mode mode;
-	const char *help;
-	/** a string listing the options and arguments, required or optional */
-	const char *usage;
-
-	/**
-	 * If non-NULL, the commands in @c chain will be registered in
-	 * the same context and scope of this registration record.
-	 * This allows modules to inherit lists commands from other
-	 * modules.
-	 */
-	const struct command_registration *chain;
-};
-
-/** Use this as the last entry in an array of command_registration records. */
-#define COMMAND_REGISTRATION_DONE { .name = NULL, .chain = NULL }
-
-/**
- * Register a command @c handler that can be called from scripts during
- * the execution @c mode specified.
- *
- * If @c parent is non-NULL, the new command will be registered as a
- * sub-command under it; otherwise, it will be available as a top-level
- * command.
- *
- * @param cmd_ctx The command_context in which to register the command.
- * @param parent Register this command as a child of this, or NULL to
- * register a top-level command.
- * @param rec A command_registration record that contains the desired
- * command parameters.
- * @returns The new command, if successful; otherwise, NULL.
- */
-struct command *register_command(struct command_context *cmd_ctx,
-				 struct command *parent, const struct command_registration *rec);
-
-/**
- * Register one or more commands in the specified context, as children
- * of @c parent (or top-level commends, if NULL).  In a registration's
- * record contains a non-NULL @c chain member and name is NULL, the
- * commands on the chain will be registered in the same context.
- * Otherwise, the chained commands are added as children of the command.
- *
- * @param cmd_ctx The command_context in which to register the command.
- * @param parent Register this command as a child of this, or NULL to
- * register a top-level command.
- * @param cmds Pointer to an array of command_registration records that
- * contains the desired command parameters.  The last record must have
- * NULL for all fields.
- * @returns ERROR_OK on success; ERROR_FAIL if any registration fails.
- */
-int register_commands(struct command_context *cmd_ctx, struct command *parent,
-		const struct command_registration *cmds);
-
-
-/**
- * Unregisters command @c name from the given context, @c cmd_ctx.
- * @param cmd_ctx The context of the registered command.
- * @param parent The parent of the given command, or NULL.
- * @param name The name of the command to unregister.
- * @returns ERROR_OK on success, or an error code.
- */
-int unregister_command(struct command_context *cmd_ctx,
-		struct command *parent, const char *name);
-/**
- * Unregisters all commands from the specfied context.
- * @param cmd_ctx The context that will be cleared of registered commands.
- * @param parent If given, only clear commands from under this one command.
- * @returns ERROR_OK on success, or an error code.
- */
-int unregister_all_commands(struct command_context *cmd_ctx,
-		struct command *parent);
-
-struct command *command_find_in_context(struct command_context *cmd_ctx,
-		const char *name);
-struct command *command_find_in_parent(struct command *parent,
-		const char *name);
-
-/**
- * Update the private command data field for a command and all descendents.
- * This is used when creating a new heirarchy of commands that depends
- * on obtaining a dynamically created context.  The value will be available
- * in command handlers by using the CMD_DATA macro.
- * @param c The command (group) whose data pointer(s) will be updated.
- * @param p The new data pointer to use for the command or its descendents.
- */
-void command_set_handler_data(struct command *c, void *p);
-
-void command_set_output_handler(struct command_context *context,
-		command_output_handler_t output_handler, void *priv);
-
-
-int command_context_mode(struct command_context *context, enum command_mode mode);
-
-/* Return the current command context associated with the Jim interpreter or
- * alternatively the global default command interpreter
- */
-struct command_context *current_command_context(Jim_Interp *interp);
-/**
- * Creates a new command context using the startup TCL provided and
- * the existing Jim interpreter, if any. If interp == NULL, then command_init
- * creates a command interpreter.
- */
-struct command_context *command_init(const char *startup_tcl, Jim_Interp *interp);
-/**
- * Creates a copy of an existing command context.  This does not create
- * a deep copy of the command list, so modifications in one context will
- * affect all shared contexts.  The caller must track reference counting
- * and ensure the commands are freed before destroying the last instance.
- * @param cmd_ctx The command_context that will be copied.
- * @returns A new command_context with the same state as the original.
- */
-struct command_context *copy_command_context(struct command_context *cmd_ctx);
-/**
- * Frees the resources associated with a command context.  The commands
- * are not removed, so unregister_all_commands() must be called first.
- * @param context The command_context that will be destroyed.
- */
-void command_done(struct command_context *context);
-
-void command_print(struct command_context *context, const char *format, ...)
-__attribute__ ((format (PRINTF_ATTRIBUTE_FORMAT, 2, 3)));
-void command_print_sameline(struct command_context *context, const char *format, ...)
-__attribute__ ((format (PRINTF_ATTRIBUTE_FORMAT, 2, 3)));
-int command_run_line(struct command_context *context, char *line);
-int command_run_linef(struct command_context *context, const char *format, ...)
-__attribute__ ((format (PRINTF_ATTRIBUTE_FORMAT, 2, 3)));
-void command_output_text(struct command_context *context, const char *data);
-
-void process_jim_events(struct command_context *cmd_ctx);
-
-#define ERROR_COMMAND_CLOSE_CONNECTION		(-600)
-#define ERROR_COMMAND_SYNTAX_ERROR			(-601)
-#define ERROR_COMMAND_NOTFOUND				(-602)
-#define ERROR_COMMAND_ARGUMENT_INVALID		(-603)
-#define ERROR_COMMAND_ARGUMENT_OVERFLOW		(-604)
-#define ERROR_COMMAND_ARGUMENT_UNDERFLOW	(-605)
-
-int parse_ulong(const char *str, unsigned long *ul);
-int parse_ullong(const char *str, unsigned long long *ul);
-
-int parse_long(const char *str, long *ul);
-int parse_llong(const char *str, long long *ul);
-
-#define DECLARE_PARSE_WRAPPER(name, type) \
-		int parse ## name(const char *str, type * ul)
-
-DECLARE_PARSE_WRAPPER(_uint, unsigned);
-DECLARE_PARSE_WRAPPER(_u64, uint64_t);
-DECLARE_PARSE_WRAPPER(_u32, uint32_t);
-DECLARE_PARSE_WRAPPER(_u16, uint16_t);
-DECLARE_PARSE_WRAPPER(_u8, uint8_t);
-
-DECLARE_PARSE_WRAPPER(_int, int);
-DECLARE_PARSE_WRAPPER(_s32, int32_t);
-DECLARE_PARSE_WRAPPER(_s16, int16_t);
-DECLARE_PARSE_WRAPPER(_s8, int8_t);
-
-/**
- * @brief parses the string @a in into @a out as a @a type, or prints
- * a command error and passes the error code to the caller.  If an error
- * does occur, the calling function will return the error code produced
- * by the parsing function (one of ERROR_COMMAND_ARGUMENT_*).
- *
- * This function may cause the calling function to return immediately,
- * so it should be used carefully to avoid leaking resources.  In most
- * situations, parsing should be completed in full before proceding
- * to allocate resources, and this strategy will most prevents leaks.
- */
-#define COMMAND_PARSE_NUMBER(type, in, out) \
-	do { \
-		int retval_macro_tmp = parse_ ## type(in, &(out)); \
-		if (ERROR_OK != retval_macro_tmp) { \
-			command_print(CMD_CTX, stringify(out) \
-				" option value ('%s') is not valid", in); \
-			return retval_macro_tmp; \
-		} \
-	} while (0)
-
-/**
- * Parse the string @c as a binary parameter, storing the boolean value
- * in @c out.  The strings @c on and @c off are used to match different
- * strings for true and false options (e.g. "on" and "off" or
- * "enable" and "disable").
- */
-#define COMMAND_PARSE_BOOL(in, out, on, off) \
-	do { \
-		bool value; \
-		int retval_macro_tmp = command_parse_bool_arg(in, &value); \
-		if (ERROR_OK != retval_macro_tmp) { \
-			command_print(CMD_CTX, stringify(out) \
-				" option value ('%s') is not valid", in); \
-			command_print(CMD_CTX, "  choices are '%s' or '%s'", \
-				on, off); \
-			return retval_macro_tmp; \
-		} \
-		out = value; \
-	} while (0)
-
-int command_parse_bool_arg(const char *in, bool *out);
-COMMAND_HELPER(handle_command_parse_bool, bool *out, const char *label);
-
-/** parses an on/off command argument */
-#define COMMAND_PARSE_ON_OFF(in, out) \
-	COMMAND_PARSE_BOOL(in, out, "on", "off")
-/** parses an enable/disable command argument */
-#define COMMAND_PARSE_ENABLE(in, out) \
-	COMMAND_PARSE_BOOL(in, out, "enable", "disable")
-
-void script_debug(Jim_Interp *interp, const char *cmd,
-		  unsigned argc, Jim_Obj * const *argv);
-
-#endif	/* COMMAND_H */

http://git-wip-us.apache.org/repos/asf/incubator-mynewt-site/blob/69f466b5/docs/os/tutorials/downloads/openocd-code-89bf96ffe6ac66c80407af8383b9d5adc0dc35f4/src/helper/configuration.c
----------------------------------------------------------------------
diff --git a/docs/os/tutorials/downloads/openocd-code-89bf96ffe6ac66c80407af8383b9d5adc0dc35f4/src/helper/configuration.c b/docs/os/tutorials/downloads/openocd-code-89bf96ffe6ac66c80407af8383b9d5adc0dc35f4/src/helper/configuration.c
deleted file mode 100755
index dde1491..0000000
--- a/docs/os/tutorials/downloads/openocd-code-89bf96ffe6ac66c80407af8383b9d5adc0dc35f4/src/helper/configuration.c
+++ /dev/null
@@ -1,172 +0,0 @@
-/***************************************************************************
- *   Copyright (C) 2004, 2005 by Dominic Rath                              *
- *   Dominic.Rath@gmx.de                                                   *
- *                                                                         *
- *   Copyright (C) 2007,2008 �yvind Harboe                                 *
- *   oyvind.harboe@zylin.com                                               *
- *                                                                         *
- *   This program is free software; you can redistribute it and/or modify  *
- *   it under the terms of the GNU General Public License as published by  *
- *   the Free Software Foundation; either version 2 of the License, or     *
- *   (at your option) any later version.                                   *
- *                                                                         *
- *   This program is distributed in the hope that it will be useful,       *
- *   but WITHOUT ANY WARRANTY; without even the implied warranty of        *
- *   MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE.  See the         *
- *   GNU General Public License for more details.                          *
- *                                                                         *
- *   You should have received a copy of the GNU General Public License     *
- *   along with this program; if not, write to the                         *
- *   Free Software Foundation, Inc.,                                       *
- *   51 Franklin Street, Fifth Floor, Boston, MA 02110-1301 USA.           *
- ***************************************************************************/
-#ifdef HAVE_CONFIG_H
-#include "config.h"
-#endif
-
-#include "configuration.h"
-#include "log.h"
-
-static size_t num_config_files;
-static char **config_file_names;
-
-static size_t num_script_dirs;
-static char **script_search_dirs;
-
-void add_script_search_dir(const char *dir)
-{
-	num_script_dirs++;
-	script_search_dirs = realloc(script_search_dirs, (num_script_dirs + 1) * sizeof(char *));
-
-	script_search_dirs[num_script_dirs-1] = strdup(dir);
-	script_search_dirs[num_script_dirs] = NULL;
-
-	LOG_DEBUG("adding %s", dir);
-}
-
-void add_config_command(const char *cfg)
-{
-	num_config_files++;
-	config_file_names = realloc(config_file_names, (num_config_files + 1) * sizeof(char *));
-
-	config_file_names[num_config_files-1] = strdup(cfg);
-	config_file_names[num_config_files] = NULL;
-}
-
-/* return full path or NULL according to search rules */
-char *find_file(const char *file)
-{
-	FILE *fp = NULL;
-	char **search_dirs = script_search_dirs;
-	char *dir;
-	char const *mode = "r";
-	char *full_path;
-
-	/* Check absolute and relative to current working dir first.
-	 * This keeps full_path reporting belowing working. */
-	full_path = alloc_printf("%s", file);
-	fp = fopen(full_path, mode);
-
-	while (!fp) {
-		free(full_path);
-		full_path = NULL;
-		dir = *search_dirs++;
-
-		if (!dir)
-			break;
-
-		full_path = alloc_printf("%s/%s", dir, file);
-		fp = fopen(full_path, mode);
-	}
-
-	if (fp) {
-		fclose(fp);
-		LOG_DEBUG("found %s", full_path);
-		return full_path;
-	}
-
-	free(full_path);
-
-	return NULL;
-}
-
-FILE *open_file_from_path(const char *file, const char *mode)
-{
-	if (mode[0] != 'r')
-		return fopen(file, mode);
-	else {
-		char *full_path = find_file(file);
-		if (full_path == NULL)
-			return NULL;
-		FILE *fp = NULL;
-		fp = fopen(full_path, mode);
-		free(full_path);
-		return fp;
-	}
-}
-
-int parse_config_file(struct command_context *cmd_ctx)
-{
-	int retval;
-	char **cfg;
-
-	if (!config_file_names) {
-		command_run_line(cmd_ctx, "script openocd.cfg");
-		return ERROR_OK;
-	}
-
-	cfg = config_file_names;
-
-	while (*cfg) {
-		retval = command_run_line(cmd_ctx, *cfg);
-		if (retval != ERROR_OK)
-			return retval;
-		cfg++;
-	}
-
-	return ERROR_OK;
-}
-
-#ifndef _WIN32
-#include <pwd.h>
-#endif
-
-char *get_home_dir(const char *append_path)
-{
-	char *home = getenv("HOME");
-
-	if (home == NULL) {
-
-#ifdef _WIN32
-		home = getenv("USERPROFILE");
-
-		if (home == NULL) {
-
-			char homepath[MAX_PATH];
-			char *drive = getenv("HOMEDRIVE");
-			char *path = getenv("HOMEPATH");
-			if (drive && path) {
-				snprintf(homepath, MAX_PATH, "%s/%s", drive, path);
-				home = homepath;
-			}
-		}
-#else
-		struct passwd *pwd = getpwuid(getuid());
-		if (pwd)
-			home = pwd->pw_dir;
-
-#endif
-	}
-
-	if (home == NULL)
-		return home;
-
-	char *home_path;
-
-	if (append_path)
-		home_path = alloc_printf("%s/%s", home, append_path);
-	else
-		home_path = alloc_printf("%s", home);
-
-	return home_path;
-}

http://git-wip-us.apache.org/repos/asf/incubator-mynewt-site/blob/69f466b5/docs/os/tutorials/downloads/openocd-code-89bf96ffe6ac66c80407af8383b9d5adc0dc35f4/src/helper/configuration.h
----------------------------------------------------------------------
diff --git a/docs/os/tutorials/downloads/openocd-code-89bf96ffe6ac66c80407af8383b9d5adc0dc35f4/src/helper/configuration.h b/docs/os/tutorials/downloads/openocd-code-89bf96ffe6ac66c80407af8383b9d5adc0dc35f4/src/helper/configuration.h
deleted file mode 100755
index 7b9f711..0000000
--- a/docs/os/tutorials/downloads/openocd-code-89bf96ffe6ac66c80407af8383b9d5adc0dc35f4/src/helper/configuration.h
+++ /dev/null
@@ -1,45 +0,0 @@
-/***************************************************************************
- *   Copyright (C) 2004, 2005 by Dominic Rath                              *
- *   Dominic.Rath@gmx.de                                                   *
- *                                                                         *
- *   Copyright (C) 2007,2008 �yvind Harboe                                 *
- *   oyvind.harboe@zylin.com                                               *
- *                                                                         *
- *   This program is free software; you can redistribute it and/or modify  *
- *   it under the terms of the GNU General Public License as published by  *
- *   the Free Software Foundation; either version 2 of the License, or     *
- *   (at your option) any later version.                                   *
- *                                                                         *
- *   This program is distributed in the hope that it will be useful,       *
- *   but WITHOUT ANY WARRANTY; without even the implied warranty of        *
- *   MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE.  See the         *
- *   GNU General Public License for more details.                          *
- *                                                                         *
- *   You should have received a copy of the GNU General Public License     *
- *   along with this program; if not, write to the                         *
- *   Free Software Foundation, Inc.,                                       *
- *   51 Franklin Street, Fifth Floor, Boston, MA 02110-1301 USA.           *
- ***************************************************************************/
-
-#ifndef CONFIGURATION_H
-#define CONFIGURATION_H
-
-#include <helper/command.h>
-
-int parse_cmdline_args(struct command_context *cmd_ctx,
-		int argc, char *argv[]);
-
-int parse_config_file(struct command_context *cmd_ctx);
-void add_config_command(const char *cfg);
-
-void add_script_search_dir(const char *dir);
-
-int configuration_output_handler(struct command_context *cmd_ctx,
-		const char *line);
-
-FILE *open_file_from_path(const char *file, const char *mode);
-
-char *find_file(const char *name);
-char *get_home_dir(const char *append_path);
-
-#endif	/* CONFIGURATION_H */

http://git-wip-us.apache.org/repos/asf/incubator-mynewt-site/blob/69f466b5/docs/os/tutorials/downloads/openocd-code-89bf96ffe6ac66c80407af8383b9d5adc0dc35f4/src/helper/fileio.c
----------------------------------------------------------------------
diff --git a/docs/os/tutorials/downloads/openocd-code-89bf96ffe6ac66c80407af8383b9d5adc0dc35f4/src/helper/fileio.c b/docs/os/tutorials/downloads/openocd-code-89bf96ffe6ac66c80407af8383b9d5adc0dc35f4/src/helper/fileio.c
deleted file mode 100755
index 9864b5f..0000000
--- a/docs/os/tutorials/downloads/openocd-code-89bf96ffe6ac66c80407af8383b9d5adc0dc35f4/src/helper/fileio.c
+++ /dev/null
@@ -1,271 +0,0 @@
-/***************************************************************************
- *   Copyright (C) 2007 by Dominic Rath                                    *
- *   Dominic.Rath@gmx.de                                                   *
- *                                                                         *
- *   Copyright (C) 2007,2008 �yvind Harboe                                 *
- *   oyvind.harboe@zylin.com                                               *
- *                                                                         *
- *   Copyright (C) 2008 by Spencer Oliver                                  *
- *   spen@spen-soft.co.uk                                                  *
- *                                                                         *
- *   This program is free software; you can redistribute it and/or modify  *
- *   it under the terms of the GNU General Public License as published by  *
- *   the Free Software Foundation; either version 2 of the License, or     *
- *   (at your option) any later version.                                   *
- *                                                                         *
- *   This program is distributed in the hope that it will be useful,       *
- *   but WITHOUT ANY WARRANTY; without even the implied warranty of        *
- *   MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE.  See the         *
- *   GNU General Public License for more details.                          *
- *                                                                         *
- *   You should have received a copy of the GNU General Public License     *
- *   along with this program; if not, write to the                         *
- *   Free Software Foundation, Inc.,                                       *
- *   51 Franklin Street, Fifth Floor, Boston, MA 02110-1301 USA.           *
- ***************************************************************************/
-
-#ifdef HAVE_CONFIG_H
-#include "config.h"
-#endif
-
-#include "log.h"
-#include "configuration.h"
-#include "fileio.h"
-
-struct fileio {
-	char *url;
-	size_t size;
-	enum fileio_type type;
-	enum fileio_access access;
-	FILE *file;
-};
-
-static inline int fileio_close_local(struct fileio *fileio)
-{
-	int retval = fclose(fileio->file);
-	if (retval != 0) {
-		if (retval == EBADF)
-			LOG_ERROR("BUG: fileio->file not a valid file descriptor");
-		else
-			LOG_ERROR("couldn't close %s: %s", fileio->url, strerror(errno));
-
-		return ERROR_FILEIO_OPERATION_FAILED;
-	}
-
-	return ERROR_OK;
-}
-
-static inline int fileio_open_local(struct fileio *fileio)
-{
-	char file_access[4];
-	ssize_t file_size;
-
-	switch (fileio->access) {
-		case FILEIO_READ:
-			strcpy(file_access, "r");
-			break;
-		case FILEIO_WRITE:
-			strcpy(file_access, "w");
-			break;
-		case FILEIO_READWRITE:
-			strcpy(file_access, "w+");
-			break;
-		case FILEIO_APPEND:
-			strcpy(file_access, "a");
-			break;
-		case FILEIO_APPENDREAD:
-			strcpy(file_access, "a+");
-			break;
-		default:
-			LOG_ERROR("BUG: access neither read, write nor readwrite");
-			return ERROR_COMMAND_SYNTAX_ERROR;
-	}
-
-	/* win32 always opens in binary mode */
-#ifndef _WIN32
-	if (fileio->type == FILEIO_BINARY)
-#endif
-		strcat(file_access, "b");
-
-	fileio->file = open_file_from_path(fileio->url, file_access);
-	if (!fileio->file) {
-		LOG_ERROR("couldn't open %s", fileio->url);
-		return ERROR_FILEIO_OPERATION_FAILED;
-	}
-
-	file_size = 0;
-
-	if ((fileio->access != FILEIO_WRITE) || (fileio->access == FILEIO_READWRITE)) {
-		/* NB! Here we use fseek() instead of stat(), since stat is a
-		 * more advanced operation that might not apply to e.g. a disk path
-		 * that refers to e.g. a tftp client */
-		int result, result2;
-
-		result = fseek(fileio->file, 0, SEEK_END);
-
-		file_size = ftell(fileio->file);
-
-		result2 = fseek(fileio->file, 0, SEEK_SET);
-
-		if ((file_size < 0) || (result < 0) || (result2 < 0)) {
-			fileio_close_local(fileio);
-			return ERROR_FILEIO_OPERATION_FAILED;
-		}
-	}
-
-	fileio->size = file_size;
-
-	return ERROR_OK;
-}
-
-int fileio_open(struct fileio **fileio, const char *url,
-		enum fileio_access access_type, enum fileio_type type)
-{
-	int retval;
-	struct fileio *tmp;
-
-	tmp = malloc(sizeof(struct fileio));
-
-	tmp->type = type;
-	tmp->access = access_type;
-	tmp->url = strdup(url);
-
-	retval = fileio_open_local(tmp);
-
-	if (retval != ERROR_OK) {
-		free(tmp->url);
-		free(tmp);
-		return retval;
-	}
-
-	*fileio = tmp;
-
-	return ERROR_OK;
-}
-
-int fileio_close(struct fileio *fileio)
-{
-	int retval;
-
-	retval = fileio_close_local(fileio);
-
-	free(fileio->url);
-	free(fileio);
-
-	return retval;
-}
-
-int fileio_seek(struct fileio *fileio, size_t position)
-{
-	int retval;
-
-	retval = fseek(fileio->file, position, SEEK_SET);
-
-	if (retval != 0) {
-		LOG_ERROR("couldn't seek file %s: %s", fileio->url, strerror(errno));
-		return ERROR_FILEIO_OPERATION_FAILED;
-	}
-
-	return ERROR_OK;
-}
-
-static int fileio_local_read(struct fileio *fileio, size_t size, void *buffer,
-		size_t *size_read)
-{
-	ssize_t retval;
-
-	retval = fread(buffer, 1, size, fileio->file);
-	*size_read = (retval >= 0) ? retval : 0;
-
-	return (retval < 0) ? retval : ERROR_OK;
-}
-
-int fileio_read(struct fileio *fileio, size_t size, void *buffer,
-		size_t *size_read)
-{
-	return fileio_local_read(fileio, size, buffer, size_read);
-}
-
-int fileio_read_u32(struct fileio *fileio, uint32_t *data)
-{
-	int retval;
-	uint8_t buf[4];
-	size_t size_read;
-
-	retval = fileio_local_read(fileio, sizeof(uint32_t), buf, &size_read);
-
-	if (ERROR_OK == retval && sizeof(uint32_t) != size_read)
-		retval = -EIO;
-	if (ERROR_OK == retval)
-		*data = be_to_h_u32(buf);
-
-	return retval;
-}
-
-static int fileio_local_fgets(struct fileio *fileio, size_t size, void *buffer)
-{
-	if (fgets(buffer, size, fileio->file) == NULL)
-		return ERROR_FILEIO_OPERATION_FAILED;
-
-	return ERROR_OK;
-}
-
-int fileio_fgets(struct fileio *fileio, size_t size, void *buffer)
-{
-	return fileio_local_fgets(fileio, size, buffer);
-}
-
-static int fileio_local_write(struct fileio *fileio, size_t size,
-		const void *buffer, size_t *size_written)
-{
-	ssize_t retval;
-
-	retval = fwrite(buffer, 1, size, fileio->file);
-	*size_written = (retval >= 0) ? retval : 0;
-
-	return (retval < 0) ? retval : ERROR_OK;
-}
-
-int fileio_write(struct fileio *fileio, size_t size, const void *buffer,
-		size_t *size_written)
-{
-	int retval;
-
-	retval = fileio_local_write(fileio, size, buffer, size_written);
-
-	if (retval == ERROR_OK)
-		fileio->size += *size_written;
-
-	return retval;
-}
-
-int fileio_write_u32(struct fileio *fileio, uint32_t data)
-{
-	int retval;
-	uint8_t buf[4];
-	h_u32_to_be(buf, data);
-	size_t size_written;
-
-	retval = fileio_write(fileio, 4, buf, &size_written);
-
-	if (ERROR_OK == retval && size_written != sizeof(uint32_t))
-		retval = -EIO;
-
-	return retval;
-}
-
-/**
- * FIX!!!!
- *
- * For now this can not fail, but that's because a seek was executed
- * on startup.
- *
- * Avoiding the seek on startup opens up for using streams.
- *
- */
-int fileio_size(struct fileio *fileio, size_t *size)
-{
-	*size = fileio->size;
-
-	return ERROR_OK;
-}

http://git-wip-us.apache.org/repos/asf/incubator-mynewt-site/blob/69f466b5/docs/os/tutorials/downloads/openocd-code-89bf96ffe6ac66c80407af8383b9d5adc0dc35f4/src/helper/fileio.h
----------------------------------------------------------------------
diff --git a/docs/os/tutorials/downloads/openocd-code-89bf96ffe6ac66c80407af8383b9d5adc0dc35f4/src/helper/fileio.h b/docs/os/tutorials/downloads/openocd-code-89bf96ffe6ac66c80407af8383b9d5adc0dc35f4/src/helper/fileio.h
deleted file mode 100755
index f10e0c4..0000000
--- a/docs/os/tutorials/downloads/openocd-code-89bf96ffe6ac66c80407af8383b9d5adc0dc35f4/src/helper/fileio.h
+++ /dev/null
@@ -1,71 +0,0 @@
-/***************************************************************************
- *   Copyright (C) 2007 by Dominic Rath                                    *
- *   Dominic.Rath@gmx.de                                                   *
- *                                                                         *
- *   Copyright (C) 2007,2008 �yvind Harboe                                 *
- *   oyvind.harboe@zylin.com                                               *
- *                                                                         *
- *   Copyright (C) 2008 by Spencer Oliver                                  *
- *   spen@spen-soft.co.uk                                                  *
- *                                                                         *
- *   This program is free software; you can redistribute it and/or modify  *
- *   it under the terms of the GNU General Public License as published by  *
- *   the Free Software Foundation; either version 2 of the License, or     *
- *   (at your option) any later version.                                   *
- *                                                                         *
- *   This program is distributed in the hope that it will be useful,       *
- *   but WITHOUT ANY WARRANTY; without even the implied warranty of        *
- *   MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE.  See the         *
- *   GNU General Public License for more details.                          *
- *                                                                         *
- *   You should have received a copy of the GNU General Public License     *
- *   along with this program; if not, write to the                         *
- *   Free Software Foundation, Inc.,                                       *
- *   51 Franklin Street, Fifth Floor, Boston, MA 02110-1301 USA.           *
- ***************************************************************************/
-
-#ifndef FILEIO_H
-#define FILEIO_H
-
-#define FILEIO_MAX_ERROR_STRING		(128)
-
-enum fileio_type {
-	FILEIO_TEXT,
-	FILEIO_BINARY,
-};
-
-enum fileio_access {
-	FILEIO_NONE,		/* open without any access (invalid mode) */
-	FILEIO_READ,		/* open for reading, position at beginning */
-	FILEIO_WRITE,		/* open for writing, position at beginning */
-	FILEIO_READWRITE,	/* open for writing, position at beginning, allow reading */
-	FILEIO_APPEND,		/* open for writing, position at end */
-	FILEIO_APPENDREAD,	/* open for writing, position at end, allow reading */
-};
-
-struct fileio;
-
-int fileio_open(struct fileio **fileio, const char *url,
-		enum fileio_access access_type, enum fileio_type type);
-int fileio_close(struct fileio *fileio);
-
-int fileio_seek(struct fileio *fileio, size_t position);
-int fileio_fgets(struct fileio *fileio, size_t size, void *buffer);
-
-int fileio_read(struct fileio *fileio,
-		size_t size, void *buffer, size_t *size_read);
-int fileio_write(struct fileio *fileio,
-		size_t size, const void *buffer, size_t *size_written);
-
-int fileio_read_u32(struct fileio *fileio, uint32_t *data);
-int fileio_write_u32(struct fileio *fileio, uint32_t data);
-int fileio_size(struct fileio *fileio, size_t *size);
-
-#define ERROR_FILEIO_LOCATION_UNKNOWN			(-1200)
-#define ERROR_FILEIO_NOT_FOUND					(-1201)
-#define ERROR_FILEIO_OPERATION_FAILED			(-1202)
-#define ERROR_FILEIO_ACCESS_NOT_SUPPORTED		(-1203)
-#define ERROR_FILEIO_RESOURCE_TYPE_UNKNOWN		(-1204)
-#define ERROR_FILEIO_OPERATION_NOT_SUPPORTED	(-1205)
-
-#endif	/* FILEIO_H */