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/15 22:03:48 UTC

[05/51] [partial] incubator-mynewt-site git commit: Fixed broken Quick Start link and added OpenOCD option for Arduino Primo debugging

http://git-wip-us.apache.org/repos/asf/incubator-mynewt-site/blob/e302582d/docs/os/tutorials/downloads/openocd-code-89bf96ffe6ac66c80407af8383b9d5adc0dc35f4/src/jtag/aice/aice_usb.h
----------------------------------------------------------------------
diff --git a/docs/os/tutorials/downloads/openocd-code-89bf96ffe6ac66c80407af8383b9d5adc0dc35f4/src/jtag/aice/aice_usb.h b/docs/os/tutorials/downloads/openocd-code-89bf96ffe6ac66c80407af8383b9d5adc0dc35f4/src/jtag/aice/aice_usb.h
new file mode 100755
index 0000000..adb027e
--- /dev/null
+++ b/docs/os/tutorials/downloads/openocd-code-89bf96ffe6ac66c80407af8383b9d5adc0dc35f4/src/jtag/aice/aice_usb.h
@@ -0,0 +1,133 @@
+/***************************************************************************
+ *   Copyright (C) 2013 by Andes Technology                                *
+ *   Hsiangkai Wang <hk...@andestech.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 __AICE_USB_H__
+#define __AICE_USB_H__
+
+#include "aice_port.h"
+
+/* AICE USB timeout value */
+#define AICE_USB_TIMEOUT				5000
+
+/* AICE USB buffer size */
+#define AICE_IN_BUFFER_SIZE				2048
+#define AICE_OUT_BUFFER_SIZE			2048
+#define AICE_IN_PACKETS_BUFFER_SIZE		2048
+#define AICE_OUT_PACKETS_BUFFER_SIZE	2048
+#define AICE_IN_BATCH_COMMAND_SIZE		512
+#define AICE_OUT_BATCH_COMMAND_SIZE		512
+#define AICE_IN_PACK_COMMAND_SIZE		2048
+#define AICE_OUT_PACK_COMMAND_SIZE		2048
+
+/* Constants for AICE command READ_CTRL */
+#define AICE_READ_CTRL_GET_ICE_STATE		0x00
+#define AICE_READ_CTRL_GET_HARDWARE_VERSION	0x01
+#define AICE_READ_CTRL_GET_FPGA_VERSION		0x02
+#define AICE_READ_CTRL_GET_FIRMWARE_VERSION	0x03
+#define AICE_READ_CTRL_GET_JTAG_PIN_STATUS	0x04
+#define AICE_READ_CTRL_BATCH_BUF_INFO		0x22
+#define AICE_READ_CTRL_BATCH_STATUS			0x23
+#define AICE_READ_CTRL_BATCH_BUF0_STATE		0x31
+#define AICE_READ_CTRL_BATCH_BUF4_STATE		0x39
+#define AICE_READ_CTRL_BATCH_BUF5_STATE		0x3b
+
+/* Constants for AICE command WRITE_CTRL */
+#define AICE_WRITE_CTRL_TCK_CONTROL				0x00
+#define AICE_WRITE_CTRL_JTAG_PIN_CONTROL		0x01
+#define AICE_WRITE_CTRL_CLEAR_TIMEOUT_STATUS	0x02
+#define AICE_WRITE_CTRL_RESERVED				0x03
+#define AICE_WRITE_CTRL_JTAG_PIN_STATUS			0x04
+#define AICE_WRITE_CTRL_CUSTOM_DELAY			0x0d
+#define AICE_WRITE_CTRL_BATCH_CTRL				0x20
+#define AICE_WRITE_CTRL_BATCH_ITERATION			0x21
+#define AICE_WRITE_CTRL_BATCH_DIM_SIZE			0x22
+#define AICE_WRITE_CTRL_BATCH_CMD_BUF0_CTRL		0x30
+#define AICE_WRITE_CTRL_BATCH_DATA_BUF0_CTRL	0x38
+#define AICE_WRITE_CTRL_BATCH_DATA_BUF1_CTRL	0x3a
+
+#define AICE_BATCH_COMMAND_BUFFER_0			0x0
+#define AICE_BATCH_COMMAND_BUFFER_1			0x1
+#define AICE_BATCH_COMMAND_BUFFER_2			0x2
+#define AICE_BATCH_COMMAND_BUFFER_3			0x3
+#define AICE_BATCH_DATA_BUFFER_0			0x4
+#define AICE_BATCH_DATA_BUFFER_1			0x5
+#define AICE_BATCH_DATA_BUFFER_2			0x6
+#define AICE_BATCH_DATA_BUFFER_3			0x7
+
+/* Constants for AICE command WRITE_CTRL:TCK_CONTROL */
+#define AICE_TCK_CONTROL_TCK3048		0x08
+
+/* Constants for AICE command WRITE_CTRL:JTAG_PIN_CONTROL */
+#define AICE_JTAG_PIN_CONTROL_SRST		0x01
+#define AICE_JTAG_PIN_CONTROL_TRST		0x02
+#define AICE_JTAG_PIN_CONTROL_STOP		0x04
+#define AICE_JTAG_PIN_CONTROL_RESTART	0x08
+
+/* Constants for AICE command WRITE_CTRL:TCK_CONTROL */
+#define AICE_TCK_CONTROL_TCK_SCAN		0x10
+
+/* Custom SRST/DBGI/TRST */
+#define AICE_CUSTOM_DELAY_SET_SRST		0x01
+#define AICE_CUSTOM_DELAY_CLEAN_SRST	0x02
+#define AICE_CUSTOM_DELAY_SET_DBGI		0x04
+#define AICE_CUSTOM_DELAY_CLEAN_DBGI	0x08
+#define AICE_CUSTOM_DELAY_SET_TRST		0x10
+#define AICE_CUSTOM_DELAY_CLEAN_TRST	0x20
+
+struct aice_usb_handler_s {
+	unsigned int usb_read_ep;
+	unsigned int usb_write_ep;
+	struct jtag_libusb_device_handle *usb_handle;
+};
+
+struct cache_info {
+	uint32_t set;
+	uint32_t way;
+	uint32_t line_size;
+
+	uint32_t log2_set;
+	uint32_t log2_line_size;
+};
+
+struct aice_nds32_info {
+	uint32_t edm_version;
+	uint32_t r0_backup;
+	uint32_t r1_backup;
+	uint32_t host_dtr_backup;
+	uint32_t target_dtr_backup;
+	uint32_t edmsw_backup;
+	uint32_t edm_ctl_backup;
+	bool debug_under_dex_on;
+	bool dex_use_psw_on;
+	bool host_dtr_valid;
+	bool target_dtr_valid;
+	enum nds_memory_access access_channel;
+	enum nds_memory_select memory_select;
+	enum aice_target_state_s core_state;
+	bool cache_init;
+	struct cache_info icache;
+	struct cache_info dcache;
+};
+
+extern struct aice_port_api_s aice_usb_api;
+
+int aice_read_ctrl(uint32_t address, uint32_t *data);
+int aice_write_ctrl(uint32_t address, uint32_t data);
+
+#endif

http://git-wip-us.apache.org/repos/asf/incubator-mynewt-site/blob/e302582d/docs/os/tutorials/downloads/openocd-code-89bf96ffe6ac66c80407af8383b9d5adc0dc35f4/src/jtag/commands.c
----------------------------------------------------------------------
diff --git a/docs/os/tutorials/downloads/openocd-code-89bf96ffe6ac66c80407af8383b9d5adc0dc35f4/src/jtag/commands.c b/docs/os/tutorials/downloads/openocd-code-89bf96ffe6ac66c80407af8383b9d5adc0dc35f4/src/jtag/commands.c
new file mode 100755
index 0000000..750ebab
--- /dev/null
+++ b/docs/os/tutorials/downloads/openocd-code-89bf96ffe6ac66c80407af8383b9d5adc0dc35f4/src/jtag/commands.c
@@ -0,0 +1,255 @@
+/***************************************************************************
+ *   Copyright (C) 2005 by Dominic Rath                                    *
+ *   Dominic.Rath@gmx.de                                                   *
+ *                                                                         *
+ *   Copyright (C) 2007,2008 �yvind Harboe                                 *
+ *   oyvind.harboe@zylin.com                                               *
+ *                                                                         *
+ *   Copyright (C) 2009 SoftPLC Corporation                                *
+ *       http://softplc.com                                                *
+ *   dick@softplc.com                                                      *
+ *                                                                         *
+ *   Copyright (C) 2009 Zachary T Welch                                    *
+ *   zw@superlucidity.net                                                  *
+ *                                                                         *
+ *   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 <jtag/jtag.h>
+#include "commands.h"
+
+struct cmd_queue_page {
+	struct cmd_queue_page *next;
+	void *address;
+	size_t used;
+};
+
+#define CMD_QUEUE_PAGE_SIZE (1024 * 1024)
+static struct cmd_queue_page *cmd_queue_pages;
+static struct cmd_queue_page *cmd_queue_pages_tail;
+
+struct jtag_command *jtag_command_queue;
+static struct jtag_command **next_command_pointer = &jtag_command_queue;
+
+void jtag_queue_command(struct jtag_command *cmd)
+{
+	/* this command goes on the end, so ensure the queue terminates */
+	cmd->next = NULL;
+
+	struct jtag_command **last_cmd = next_command_pointer;
+	assert(NULL != last_cmd);
+	assert(NULL == *last_cmd);
+	*last_cmd = cmd;
+
+	/* store location where the next command pointer will be stored */
+	next_command_pointer = &cmd->next;
+}
+
+void *cmd_queue_alloc(size_t size)
+{
+	struct cmd_queue_page **p_page = &cmd_queue_pages;
+	int offset;
+	uint8_t *t;
+
+	/*
+	 * WARNING:
+	 *    We align/round the *SIZE* per below
+	 *    so that all pointers returned by
+	 *    this function are reasonably well
+	 *    aligned.
+	 *
+	 * If we did not, then an "odd-length" request would cause the
+	 * *next* allocation to be at an *odd* address, and because
+	 * this function has the same type of api as malloc() - we
+	 * must also return pointers that have the same type of
+	 * alignment.
+	 *
+	 * What I do not/have is a reasonable portable means
+	 * to align by...
+	 *
+	 * The solution here, is based on these suggestions.
+	 * http://gcc.gnu.org/ml/gcc-help/2008-12/msg00041.html
+	 *
+	 */
+	union worse_case_align {
+		int i;
+		long l;
+		float f;
+		void *v;
+	};
+#define ALIGN_SIZE  (sizeof(union worse_case_align))
+
+	/* The alignment process. */
+	size = (size + ALIGN_SIZE - 1) & (~(ALIGN_SIZE - 1));
+	/* Done... */
+
+	if (*p_page) {
+		p_page = &cmd_queue_pages_tail;
+		if (CMD_QUEUE_PAGE_SIZE - (*p_page)->used < size)
+			p_page = &((*p_page)->next);
+	}
+
+	if (!*p_page) {
+		*p_page = malloc(sizeof(struct cmd_queue_page));
+		(*p_page)->used = 0;
+		size_t alloc_size = (size < CMD_QUEUE_PAGE_SIZE) ?
+					CMD_QUEUE_PAGE_SIZE : size;
+		(*p_page)->address = malloc(alloc_size);
+		(*p_page)->next = NULL;
+		cmd_queue_pages_tail = *p_page;
+	}
+
+	offset = (*p_page)->used;
+	(*p_page)->used += size;
+
+	t = (*p_page)->address;
+	return t + offset;
+}
+
+static void cmd_queue_free(void)
+{
+	struct cmd_queue_page *page = cmd_queue_pages;
+
+	while (page) {
+		struct cmd_queue_page *last = page;
+		free(page->address);
+		page = page->next;
+		free(last);
+	}
+
+	cmd_queue_pages = NULL;
+	cmd_queue_pages_tail = NULL;
+}
+
+void jtag_command_queue_reset(void)
+{
+	cmd_queue_free();
+
+	jtag_command_queue = NULL;
+	next_command_pointer = &jtag_command_queue;
+}
+
+enum scan_type jtag_scan_type(const struct scan_command *cmd)
+{
+	int i;
+	int type = 0;
+
+	for (i = 0; i < cmd->num_fields; i++) {
+		if (cmd->fields[i].in_value)
+			type |= SCAN_IN;
+		if (cmd->fields[i].out_value)
+			type |= SCAN_OUT;
+	}
+
+	return type;
+}
+
+int jtag_scan_size(const struct scan_command *cmd)
+{
+	int bit_count = 0;
+	int i;
+
+	/* count bits in scan command */
+	for (i = 0; i < cmd->num_fields; i++)
+		bit_count += cmd->fields[i].num_bits;
+
+	return bit_count;
+}
+
+int jtag_build_buffer(const struct scan_command *cmd, uint8_t **buffer)
+{
+	int bit_count = 0;
+	int i;
+
+	bit_count = jtag_scan_size(cmd);
+	*buffer = calloc(1, DIV_ROUND_UP(bit_count, 8));
+
+	bit_count = 0;
+
+	DEBUG_JTAG_IO("%s num_fields: %i",
+			cmd->ir_scan ? "IRSCAN" : "DRSCAN",
+			cmd->num_fields);
+
+	for (i = 0; i < cmd->num_fields; i++) {
+		if (cmd->fields[i].out_value) {
+#ifdef _DEBUG_JTAG_IO_
+			char *char_buf = buf_to_str(cmd->fields[i].out_value,
+				(cmd->fields[i].num_bits > DEBUG_JTAG_IOZ)
+					? DEBUG_JTAG_IOZ
+					: cmd->fields[i].num_bits, 16);
+
+			LOG_DEBUG("fields[%i].out_value[%i]: 0x%s", i,
+					cmd->fields[i].num_bits, char_buf);
+			free(char_buf);
+#endif
+			buf_set_buf(cmd->fields[i].out_value, 0, *buffer,
+					bit_count, cmd->fields[i].num_bits);
+		} else {
+			DEBUG_JTAG_IO("fields[%i].out_value[%i]: NULL",
+					i, cmd->fields[i].num_bits);
+		}
+
+		bit_count += cmd->fields[i].num_bits;
+	}
+
+	/*DEBUG_JTAG_IO("bit_count totalling: %i",  bit_count); */
+
+	return bit_count;
+}
+
+int jtag_read_buffer(uint8_t *buffer, const struct scan_command *cmd)
+{
+	int i;
+	int bit_count = 0;
+	int retval;
+
+	/* we return ERROR_OK, unless a check fails, or a handler reports a problem */
+	retval = ERROR_OK;
+
+	for (i = 0; i < cmd->num_fields; i++) {
+		/* if neither in_value nor in_handler
+		 * are specified we don't have to examine this field
+		 */
+		if (cmd->fields[i].in_value) {
+			int num_bits = cmd->fields[i].num_bits;
+			uint8_t *captured = buf_set_buf(buffer, bit_count,
+					malloc(DIV_ROUND_UP(num_bits, 8)), 0, num_bits);
+
+#ifdef _DEBUG_JTAG_IO_
+			char *char_buf = buf_to_str(captured,
+					(num_bits > DEBUG_JTAG_IOZ)
+						? DEBUG_JTAG_IOZ
+						: num_bits, 16);
+
+			LOG_DEBUG("fields[%i].in_value[%i]: 0x%s",
+					i, num_bits, char_buf);
+			free(char_buf);
+#endif
+
+			if (cmd->fields[i].in_value)
+				buf_cpy(captured, cmd->fields[i].in_value, num_bits);
+
+			free(captured);
+		}
+		bit_count += cmd->fields[i].num_bits;
+	}
+
+	return retval;
+}

http://git-wip-us.apache.org/repos/asf/incubator-mynewt-site/blob/e302582d/docs/os/tutorials/downloads/openocd-code-89bf96ffe6ac66c80407af8383b9d5adc0dc35f4/src/jtag/commands.h
----------------------------------------------------------------------
diff --git a/docs/os/tutorials/downloads/openocd-code-89bf96ffe6ac66c80407af8383b9d5adc0dc35f4/src/jtag/commands.h b/docs/os/tutorials/downloads/openocd-code-89bf96ffe6ac66c80407af8383b9d5adc0dc35f4/src/jtag/commands.h
new file mode 100755
index 0000000..06ec248
--- /dev/null
+++ b/docs/os/tutorials/downloads/openocd-code-89bf96ffe6ac66c80407af8383b9d5adc0dc35f4/src/jtag/commands.h
@@ -0,0 +1,178 @@
+/***************************************************************************
+ *   Copyright (C) 2005 by Dominic Rath                                    *
+ *   Dominic.Rath@gmx.de                                                   *
+ *                                                                         *
+ *   Copyright (C) 2007,2008 �yvind Harboe                                 *
+ *   oyvind.harboe@zylin.com                                               *
+ *                                                                         *
+ *   Copyright (C) 2009 Zachary T Welch                                    *
+ *   zw@superlucidity.net                                                  *
+ *                                                                         *
+ *   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 JTAG_COMMANDS_H
+#define JTAG_COMMANDS_H
+
+/**
+ * The inferred type of a scan_command_s structure, indicating whether
+ * the command has the host scan in from the device, the host scan out
+ * to the device, or both.
+ */
+enum scan_type {
+	/** From device to host, */
+	SCAN_IN = 1,
+	/** From host to device, */
+	SCAN_OUT = 2,
+	/** Full-duplex scan. */
+	SCAN_IO = 3
+};
+
+/**
+ * The scan_command provide a means of encapsulating a set of scan_field_s
+ * structures that should be scanned in/out to the device.
+ */
+struct scan_command {
+	/** instruction/not data scan */
+	bool ir_scan;
+	/** number of fields in *fields array */
+	int num_fields;
+	/** pointer to an array of data scan fields */
+	struct scan_field *fields;
+	/** state in which JTAG commands should finish */
+	tap_state_t end_state;
+};
+
+struct statemove_command {
+	/** state in which JTAG commands should finish */
+	tap_state_t end_state;
+};
+
+struct pathmove_command {
+	/** number of states in *path */
+	int num_states;
+	/** states that have to be passed */
+	tap_state_t *path;
+};
+
+struct runtest_command {
+	/** number of cycles to spend in Run-Test/Idle state */
+	int num_cycles;
+	/** state in which JTAG commands should finish */
+	tap_state_t end_state;
+};
+
+
+struct stableclocks_command {
+	/** number of clock cycles that should be sent */
+	int num_cycles;
+};
+
+
+struct reset_command {
+	/** Set TRST output: 0 = deassert, 1 = assert, -1 = no change */
+	int trst;
+	/** Set SRST output: 0 = deassert, 1 = assert, -1 = no change */
+	int srst;
+};
+
+struct end_state_command {
+	/** state in which JTAG commands should finish */
+	tap_state_t end_state;
+};
+
+struct sleep_command {
+	/** number of microseconds to sleep */
+	uint32_t us;
+};
+
+/**
+ * Encapsulates a series of bits to be clocked out, affecting state
+ * and mode of the interface.
+ *
+ * In JTAG mode these are clocked out on TMS, using TCK.  They may be
+ * used for link resets, transitioning between JTAG and SWD modes, or
+ * to implement JTAG state machine transitions (implementing pathmove
+ * or statemove operations).
+ *
+ * In SWD mode these are clocked out on SWDIO, using SWCLK, and are
+ * used for link resets and transitioning between SWD and JTAG modes.
+ */
+struct tms_command {
+	/** How many bits should be clocked out. */
+	unsigned num_bits;
+	/** The bits to clock out; the LSB is bit 0 of bits[0]. */
+	const uint8_t *bits;
+};
+
+/**
+ * Defines a container type that hold a pointer to a JTAG command
+ * structure of any defined type.
+ */
+union jtag_command_container {
+	struct scan_command *scan;
+	struct statemove_command *statemove;
+	struct pathmove_command *pathmove;
+	struct runtest_command *runtest;
+	struct stableclocks_command *stableclocks;
+	struct reset_command *reset;
+	struct end_state_command *end_state;
+	struct sleep_command *sleep;
+	struct tms_command *tms;
+};
+
+/**
+ * The type of the @c jtag_command_container contained by a
+ * @c jtag_command_s structure.
+ */
+enum jtag_command_type {
+	JTAG_SCAN         = 1,
+	/* JTAG_TLR_RESET's non-minidriver implementation is a
+	 * vestige from a statemove cmd. The statemove command
+	 * is obsolete and replaced by pathmove.
+	 *
+	 * pathmove does not support reset as one of it's states,
+	 * hence the need for an explicit statemove command.
+	 */
+	JTAG_TLR_RESET    = 2,
+	JTAG_RUNTEST      = 3,
+	JTAG_RESET        = 4,
+	JTAG_PATHMOVE     = 6,
+	JTAG_SLEEP        = 7,
+	JTAG_STABLECLOCKS = 8,
+	JTAG_TMS          = 9,
+};
+
+struct jtag_command {
+	union jtag_command_container cmd;
+	enum jtag_command_type type;
+	struct jtag_command *next;
+};
+
+/** The current queue of jtag_command_s structures. */
+extern struct jtag_command *jtag_command_queue;
+
+void *cmd_queue_alloc(size_t size);
+
+void jtag_queue_command(struct jtag_command *cmd);
+void jtag_command_queue_reset(void);
+
+enum scan_type jtag_scan_type(const struct scan_command *cmd);
+int jtag_scan_size(const struct scan_command *cmd);
+int jtag_read_buffer(uint8_t *buffer, const struct scan_command *cmd);
+int jtag_build_buffer(const struct scan_command *cmd, uint8_t **buffer);
+
+#endif /* JTAG_COMMANDS_H */

http://git-wip-us.apache.org/repos/asf/incubator-mynewt-site/blob/e302582d/docs/os/tutorials/downloads/openocd-code-89bf96ffe6ac66c80407af8383b9d5adc0dc35f4/src/jtag/core.c
----------------------------------------------------------------------
diff --git a/docs/os/tutorials/downloads/openocd-code-89bf96ffe6ac66c80407af8383b9d5adc0dc35f4/src/jtag/core.c b/docs/os/tutorials/downloads/openocd-code-89bf96ffe6ac66c80407af8383b9d5adc0dc35f4/src/jtag/core.c
new file mode 100755
index 0000000..fd4370f
--- /dev/null
+++ b/docs/os/tutorials/downloads/openocd-code-89bf96ffe6ac66c80407af8383b9d5adc0dc35f4/src/jtag/core.c
@@ -0,0 +1,1854 @@
+/***************************************************************************
+ *   Copyright (C) 2009 Zachary T Welch                                    *
+ *   zw@superlucidity.net                                                  *
+ *                                                                         *
+ *   Copyright (C) 2007,2008,2009 �yvind Harboe                            *
+ *   oyvind.harboe@zylin.com                                               *
+ *                                                                         *
+ *   Copyright (C) 2009 SoftPLC Corporation                                *
+ *       http://softplc.com                                                *
+ *   dick@softplc.com                                                      *
+ *                                                                         *
+ *   Copyright (C) 2005 by Dominic Rath                                    *
+ *   Dominic.Rath@gmx.de                                                   *
+ *                                                                         *
+ *   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 "jtag.h"
+#include "swd.h"
+#include "interface.h"
+#include <transport/transport.h>
+#include <helper/jep106.h>
+
+#ifdef HAVE_STRINGS_H
+#include <strings.h>
+#endif
+
+/* SVF and XSVF are higher level JTAG command sets (for boundary scan) */
+#include "svf/svf.h"
+#include "xsvf/xsvf.h"
+
+/** The number of JTAG queue flushes (for profiling and debugging purposes). */
+static int jtag_flush_queue_count;
+
+/* Sleep this # of ms after flushing the queue */
+static int jtag_flush_queue_sleep;
+
+static void jtag_add_scan_check(struct jtag_tap *active,
+		void (*jtag_add_scan)(struct jtag_tap *active,
+		int in_num_fields,
+		const struct scan_field *in_fields,
+		tap_state_t state),
+		int in_num_fields, struct scan_field *in_fields, tap_state_t state);
+
+/**
+ * The jtag_error variable is set when an error occurs while executing
+ * the queue.  Application code may set this using jtag_set_error(),
+ * when an error occurs during processing that should be reported during
+ * jtag_execute_queue().
+ *
+ * The value is set and cleared, but never read by normal application code.
+ *
+ * This value is returned (and cleared) by jtag_execute_queue().
+ */
+static int jtag_error = ERROR_OK;
+
+static const char *jtag_event_strings[] = {
+	[JTAG_TRST_ASSERTED] = "TAP reset",
+	[JTAG_TAP_EVENT_SETUP] = "TAP setup",
+	[JTAG_TAP_EVENT_ENABLE] = "TAP enabled",
+	[JTAG_TAP_EVENT_DISABLE] = "TAP disabled",
+};
+
+/*
+ * JTAG adapters must initialize with TRST and SRST de-asserted
+ * (they're negative logic, so that means *high*).  But some
+ * hardware doesn't necessarily work that way ... so set things
+ * up so that jtag_init() always forces that state.
+ */
+static int jtag_trst = -1;
+static int jtag_srst = -1;
+
+/**
+ * List all TAPs that have been created.
+ */
+static struct jtag_tap *__jtag_all_taps;
+
+static enum reset_types jtag_reset_config = RESET_NONE;
+tap_state_t cmd_queue_cur_state = TAP_RESET;
+
+static bool jtag_verify_capture_ir = true;
+static int jtag_verify = 1;
+
+/* how long the OpenOCD should wait before attempting JTAG communication after reset lines
+ *deasserted (in ms) */
+static int adapter_nsrst_delay;	/* default to no nSRST delay */
+static int jtag_ntrst_delay;/* default to no nTRST delay */
+static int adapter_nsrst_assert_width;	/* width of assertion */
+static int jtag_ntrst_assert_width;	/* width of assertion */
+
+/**
+ * Contains a single callback along with a pointer that will be passed
+ * when an event occurs.
+ */
+struct jtag_event_callback {
+	/** a event callback */
+	jtag_event_handler_t callback;
+	/** the private data to pass to the callback */
+	void *priv;
+	/** the next callback */
+	struct jtag_event_callback *next;
+};
+
+/* callbacks to inform high-level handlers about JTAG state changes */
+static struct jtag_event_callback *jtag_event_callbacks;
+
+/* speed in kHz*/
+static int speed_khz;
+/* speed to fallback to when RCLK is requested but not supported */
+static int rclk_fallback_speed_khz;
+static enum {CLOCK_MODE_UNSELECTED, CLOCK_MODE_KHZ, CLOCK_MODE_RCLK} clock_mode;
+static int jtag_speed;
+
+static struct jtag_interface *jtag;
+
+/* configuration */
+struct jtag_interface *jtag_interface;
+
+void jtag_set_flush_queue_sleep(int ms)
+{
+	jtag_flush_queue_sleep = ms;
+}
+
+void jtag_set_error(int error)
+{
+	if ((error == ERROR_OK) || (jtag_error != ERROR_OK))
+		return;
+	jtag_error = error;
+}
+
+int jtag_error_clear(void)
+{
+	int temp = jtag_error;
+	jtag_error = ERROR_OK;
+	return temp;
+}
+
+/************/
+
+static bool jtag_poll = 1;
+
+bool is_jtag_poll_safe(void)
+{
+	/* Polling can be disabled explicitly with set_enabled(false).
+	 * It is also implicitly disabled while TRST is active and
+	 * while SRST is gating the JTAG clock.
+	 */
+	if (!transport_is_jtag())
+		return jtag_poll;
+
+	if (!jtag_poll || jtag_trst != 0)
+		return false;
+	return jtag_srst == 0 || (jtag_reset_config & RESET_SRST_NO_GATING);
+}
+
+bool jtag_poll_get_enabled(void)
+{
+	return jtag_poll;
+}
+
+void jtag_poll_set_enabled(bool value)
+{
+	jtag_poll = value;
+}
+
+/************/
+
+struct jtag_tap *jtag_all_taps(void)
+{
+	return __jtag_all_taps;
+};
+
+unsigned jtag_tap_count(void)
+{
+	struct jtag_tap *t = jtag_all_taps();
+	unsigned n = 0;
+	while (t) {
+		n++;
+		t = t->next_tap;
+	}
+	return n;
+}
+
+unsigned jtag_tap_count_enabled(void)
+{
+	struct jtag_tap *t = jtag_all_taps();
+	unsigned n = 0;
+	while (t) {
+		if (t->enabled)
+			n++;
+		t = t->next_tap;
+	}
+	return n;
+}
+
+/** Append a new TAP to the chain of all taps. */
+void jtag_tap_add(struct jtag_tap *t)
+{
+	unsigned jtag_num_taps = 0;
+
+	struct jtag_tap **tap = &__jtag_all_taps;
+	while (*tap != NULL) {
+		jtag_num_taps++;
+		tap = &(*tap)->next_tap;
+	}
+	*tap = t;
+	t->abs_chain_position = jtag_num_taps;
+}
+
+/* returns a pointer to the n-th device in the scan chain */
+struct jtag_tap *jtag_tap_by_position(unsigned n)
+{
+	struct jtag_tap *t = jtag_all_taps();
+
+	while (t && n-- > 0)
+		t = t->next_tap;
+
+	return t;
+}
+
+struct jtag_tap *jtag_tap_by_string(const char *s)
+{
+	/* try by name first */
+	struct jtag_tap *t = jtag_all_taps();
+
+	while (t) {
+		if (0 == strcmp(t->dotted_name, s))
+			return t;
+		t = t->next_tap;
+	}
+
+	/* no tap found by name, so try to parse the name as a number */
+	unsigned n;
+	if (parse_uint(s, &n) != ERROR_OK)
+		return NULL;
+
+	/* FIXME remove this numeric fallback code late June 2010, along
+	 * with all info in the User's Guide that TAPs have numeric IDs.
+	 * Also update "scan_chain" output to not display the numbers.
+	 */
+	t = jtag_tap_by_position(n);
+	if (t)
+		LOG_WARNING("Specify TAP '%s' by name, not number %u",
+			t->dotted_name, n);
+
+	return t;
+}
+
+struct jtag_tap *jtag_tap_next_enabled(struct jtag_tap *p)
+{
+	p = p ? p->next_tap : jtag_all_taps();
+	while (p) {
+		if (p->enabled)
+			return p;
+		p = p->next_tap;
+	}
+	return NULL;
+}
+
+const char *jtag_tap_name(const struct jtag_tap *tap)
+{
+	return (tap == NULL) ? "(unknown)" : tap->dotted_name;
+}
+
+
+int jtag_register_event_callback(jtag_event_handler_t callback, void *priv)
+{
+	struct jtag_event_callback **callbacks_p = &jtag_event_callbacks;
+
+	if (callback == NULL)
+		return ERROR_COMMAND_SYNTAX_ERROR;
+
+	if (*callbacks_p) {
+		while ((*callbacks_p)->next)
+			callbacks_p = &((*callbacks_p)->next);
+		callbacks_p = &((*callbacks_p)->next);
+	}
+
+	(*callbacks_p) = malloc(sizeof(struct jtag_event_callback));
+	(*callbacks_p)->callback = callback;
+	(*callbacks_p)->priv = priv;
+	(*callbacks_p)->next = NULL;
+
+	return ERROR_OK;
+}
+
+int jtag_unregister_event_callback(jtag_event_handler_t callback, void *priv)
+{
+	struct jtag_event_callback **p = &jtag_event_callbacks, *temp;
+
+	if (callback == NULL)
+		return ERROR_COMMAND_SYNTAX_ERROR;
+
+	while (*p) {
+		if (((*p)->priv != priv) || ((*p)->callback != callback)) {
+			p = &(*p)->next;
+			continue;
+		}
+
+		temp = *p;
+		*p = (*p)->next;
+		free(temp);
+	}
+
+	return ERROR_OK;
+}
+
+int jtag_call_event_callbacks(enum jtag_event event)
+{
+	struct jtag_event_callback *callback = jtag_event_callbacks;
+
+	LOG_DEBUG("jtag event: %s", jtag_event_strings[event]);
+
+	while (callback) {
+		struct jtag_event_callback *next;
+
+		/* callback may remove itself */
+		next = callback->next;
+		callback->callback(event, callback->priv);
+		callback = next;
+	}
+
+	return ERROR_OK;
+}
+
+static void jtag_checks(void)
+{
+	assert(jtag_trst == 0);
+}
+
+static void jtag_prelude(tap_state_t state)
+{
+	jtag_checks();
+
+	assert(state != TAP_INVALID);
+
+	cmd_queue_cur_state = state;
+}
+
+void jtag_add_ir_scan_noverify(struct jtag_tap *active, const struct scan_field *in_fields,
+	tap_state_t state)
+{
+	jtag_prelude(state);
+
+	int retval = interface_jtag_add_ir_scan(active, in_fields, state);
+	jtag_set_error(retval);
+}
+
+static void jtag_add_ir_scan_noverify_callback(struct jtag_tap *active,
+	int dummy,
+	const struct scan_field *in_fields,
+	tap_state_t state)
+{
+	jtag_add_ir_scan_noverify(active, in_fields, state);
+}
+
+/* If fields->in_value is filled out, then the captured IR value will be checked */
+void jtag_add_ir_scan(struct jtag_tap *active, struct scan_field *in_fields, tap_state_t state)
+{
+	assert(state != TAP_RESET);
+
+	if (jtag_verify && jtag_verify_capture_ir) {
+		/* 8 x 32 bit id's is enough for all invocations */
+
+		/* if we are to run a verification of the ir scan, we need to get the input back.
+		 * We may have to allocate space if the caller didn't ask for the input back.
+		 */
+		in_fields->check_value = active->expected;
+		in_fields->check_mask = active->expected_mask;
+		jtag_add_scan_check(active, jtag_add_ir_scan_noverify_callback, 1, in_fields,
+			state);
+	} else
+		jtag_add_ir_scan_noverify(active, in_fields, state);
+}
+
+void jtag_add_plain_ir_scan(int num_bits, const uint8_t *out_bits, uint8_t *in_bits,
+	tap_state_t state)
+{
+	assert(out_bits != NULL);
+	assert(state != TAP_RESET);
+
+	jtag_prelude(state);
+
+	int retval = interface_jtag_add_plain_ir_scan(
+			num_bits, out_bits, in_bits, state);
+	jtag_set_error(retval);
+}
+
+static int jtag_check_value_inner(uint8_t *captured, uint8_t *in_check_value,
+				  uint8_t *in_check_mask, int num_bits);
+
+static int jtag_check_value_mask_callback(jtag_callback_data_t data0,
+	jtag_callback_data_t data1,
+	jtag_callback_data_t data2,
+	jtag_callback_data_t data3)
+{
+	return jtag_check_value_inner((uint8_t *)data0,
+		(uint8_t *)data1,
+		(uint8_t *)data2,
+		(int)data3);
+}
+
+static void jtag_add_scan_check(struct jtag_tap *active, void (*jtag_add_scan)(
+		struct jtag_tap *active,
+		int in_num_fields,
+		const struct scan_field *in_fields,
+		tap_state_t state),
+	int in_num_fields, struct scan_field *in_fields, tap_state_t state)
+{
+	jtag_add_scan(active, in_num_fields, in_fields, state);
+
+	for (int i = 0; i < in_num_fields; i++) {
+		if ((in_fields[i].check_value != NULL) && (in_fields[i].in_value != NULL)) {
+			/* this is synchronous for a minidriver */
+			jtag_add_callback4(jtag_check_value_mask_callback,
+				(jtag_callback_data_t)in_fields[i].in_value,
+				(jtag_callback_data_t)in_fields[i].check_value,
+				(jtag_callback_data_t)in_fields[i].check_mask,
+				(jtag_callback_data_t)in_fields[i].num_bits);
+		}
+	}
+}
+
+void jtag_add_dr_scan_check(struct jtag_tap *active,
+	int in_num_fields,
+	struct scan_field *in_fields,
+	tap_state_t state)
+{
+	if (jtag_verify)
+		jtag_add_scan_check(active, jtag_add_dr_scan, in_num_fields, in_fields, state);
+	else
+		jtag_add_dr_scan(active, in_num_fields, in_fields, state);
+}
+
+
+void jtag_add_dr_scan(struct jtag_tap *active,
+	int in_num_fields,
+	const struct scan_field *in_fields,
+	tap_state_t state)
+{
+	assert(state != TAP_RESET);
+
+	jtag_prelude(state);
+
+	int retval;
+	retval = interface_jtag_add_dr_scan(active, in_num_fields, in_fields, state);
+	jtag_set_error(retval);
+}
+
+void jtag_add_plain_dr_scan(int num_bits, const uint8_t *out_bits, uint8_t *in_bits,
+	tap_state_t state)
+{
+	assert(out_bits != NULL);
+	assert(state != TAP_RESET);
+
+	jtag_prelude(state);
+
+	int retval;
+	retval = interface_jtag_add_plain_dr_scan(num_bits, out_bits, in_bits, state);
+	jtag_set_error(retval);
+}
+
+void jtag_add_tlr(void)
+{
+	jtag_prelude(TAP_RESET);
+	jtag_set_error(interface_jtag_add_tlr());
+
+	/* NOTE: order here matches TRST path in jtag_add_reset() */
+	jtag_call_event_callbacks(JTAG_TRST_ASSERTED);
+	jtag_notify_event(JTAG_TRST_ASSERTED);
+}
+
+/**
+ * If supported by the underlying adapter, this clocks a raw bit sequence
+ * onto TMS for switching betwen JTAG and SWD modes.
+ *
+ * DO NOT use this to bypass the integrity checks and logging provided
+ * by the jtag_add_pathmove() and jtag_add_statemove() calls.
+ *
+ * @param nbits How many bits to clock out.
+ * @param seq The bit sequence.  The LSB is bit 0 of seq[0].
+ * @param state The JTAG tap state to record on completion.  Use
+ *	TAP_INVALID to represent being in in SWD mode.
+ *
+ * @todo Update naming conventions to stop assuming everything is JTAG.
+ */
+int jtag_add_tms_seq(unsigned nbits, const uint8_t *seq, enum tap_state state)
+{
+	int retval;
+
+	if (!(jtag->supported & DEBUG_CAP_TMS_SEQ))
+		return ERROR_JTAG_NOT_IMPLEMENTED;
+
+	jtag_checks();
+	cmd_queue_cur_state = state;
+
+	retval = interface_add_tms_seq(nbits, seq, state);
+	jtag_set_error(retval);
+	return retval;
+}
+
+void jtag_add_pathmove(int num_states, const tap_state_t *path)
+{
+	tap_state_t cur_state = cmd_queue_cur_state;
+
+	/* the last state has to be a stable state */
+	if (!tap_is_state_stable(path[num_states - 1])) {
+		LOG_ERROR("BUG: TAP path doesn't finish in a stable state");
+		jtag_set_error(ERROR_JTAG_NOT_STABLE_STATE);
+		return;
+	}
+
+	for (int i = 0; i < num_states; i++) {
+		if (path[i] == TAP_RESET) {
+			LOG_ERROR("BUG: TAP_RESET is not a valid state for pathmove sequences");
+			jtag_set_error(ERROR_JTAG_STATE_INVALID);
+			return;
+		}
+
+		if (tap_state_transition(cur_state, true) != path[i] &&
+				tap_state_transition(cur_state, false) != path[i]) {
+			LOG_ERROR("BUG: %s -> %s isn't a valid TAP transition",
+				tap_state_name(cur_state), tap_state_name(path[i]));
+			jtag_set_error(ERROR_JTAG_TRANSITION_INVALID);
+			return;
+		}
+		cur_state = path[i];
+	}
+
+	jtag_checks();
+
+	jtag_set_error(interface_jtag_add_pathmove(num_states, path));
+	cmd_queue_cur_state = path[num_states - 1];
+}
+
+int jtag_add_statemove(tap_state_t goal_state)
+{
+	tap_state_t cur_state = cmd_queue_cur_state;
+
+	if (goal_state != cur_state) {
+		LOG_DEBUG("cur_state=%s goal_state=%s",
+			tap_state_name(cur_state),
+			tap_state_name(goal_state));
+	}
+
+	/* If goal is RESET, be paranoid and force that that transition
+	 * (e.g. five TCK cycles, TMS high).  Else trust "cur_state".
+	 */
+	if (goal_state == TAP_RESET)
+		jtag_add_tlr();
+	else if (goal_state == cur_state)
+		/* nothing to do */;
+
+	else if (tap_is_state_stable(cur_state) && tap_is_state_stable(goal_state)) {
+		unsigned tms_bits  = tap_get_tms_path(cur_state, goal_state);
+		unsigned tms_count = tap_get_tms_path_len(cur_state, goal_state);
+		tap_state_t moves[8];
+		assert(tms_count < ARRAY_SIZE(moves));
+
+		for (unsigned i = 0; i < tms_count; i++, tms_bits >>= 1) {
+			bool bit = tms_bits & 1;
+
+			cur_state = tap_state_transition(cur_state, bit);
+			moves[i] = cur_state;
+		}
+
+		jtag_add_pathmove(tms_count, moves);
+	} else if (tap_state_transition(cur_state, true)  == goal_state
+			|| tap_state_transition(cur_state, false) == goal_state)
+		jtag_add_pathmove(1, &goal_state);
+	else
+		return ERROR_FAIL;
+
+	return ERROR_OK;
+}
+
+void jtag_add_runtest(int num_cycles, tap_state_t state)
+{
+	jtag_prelude(state);
+	jtag_set_error(interface_jtag_add_runtest(num_cycles, state));
+}
+
+
+void jtag_add_clocks(int num_cycles)
+{
+	if (!tap_is_state_stable(cmd_queue_cur_state)) {
+		LOG_ERROR("jtag_add_clocks() called with TAP in unstable state \"%s\"",
+			tap_state_name(cmd_queue_cur_state));
+		jtag_set_error(ERROR_JTAG_NOT_STABLE_STATE);
+		return;
+	}
+
+	if (num_cycles > 0) {
+		jtag_checks();
+		jtag_set_error(interface_jtag_add_clocks(num_cycles));
+	}
+}
+
+void swd_add_reset(int req_srst)
+{
+	if (req_srst) {
+		if (!(jtag_reset_config & RESET_HAS_SRST)) {
+			LOG_ERROR("BUG: can't assert SRST");
+			jtag_set_error(ERROR_FAIL);
+			return;
+		}
+		req_srst = 1;
+	}
+
+	/* Maybe change SRST signal state */
+	if (jtag_srst != req_srst) {
+		int retval;
+
+		retval = interface_jtag_add_reset(0, req_srst);
+		if (retval != ERROR_OK)
+			jtag_set_error(retval);
+		else
+			retval = jtag_execute_queue();
+
+		if (retval != ERROR_OK) {
+			LOG_ERROR("TRST/SRST error");
+			return;
+		}
+
+		/* SRST resets everything hooked up to that signal */
+		jtag_srst = req_srst;
+		if (jtag_srst) {
+			LOG_DEBUG("SRST line asserted");
+			if (adapter_nsrst_assert_width)
+				jtag_add_sleep(adapter_nsrst_assert_width * 1000);
+		} else {
+			LOG_DEBUG("SRST line released");
+			if (adapter_nsrst_delay)
+				jtag_add_sleep(adapter_nsrst_delay * 1000);
+		}
+
+		retval = jtag_execute_queue();
+		if (retval != ERROR_OK) {
+			LOG_ERROR("SRST timings error");
+			return;
+		}
+	}
+}
+
+void jtag_add_reset(int req_tlr_or_trst, int req_srst)
+{
+	int trst_with_tlr = 0;
+	int new_srst = 0;
+	int new_trst = 0;
+
+	/* Without SRST, we must use target-specific JTAG operations
+	 * on each target; callers should not be requesting SRST when
+	 * that signal doesn't exist.
+	 *
+	 * RESET_SRST_PULLS_TRST is a board or chip level quirk, which
+	 * can kick in even if the JTAG adapter can't drive TRST.
+	 */
+	if (req_srst) {
+		if (!(jtag_reset_config & RESET_HAS_SRST)) {
+			LOG_ERROR("BUG: can't assert SRST");
+			jtag_set_error(ERROR_FAIL);
+			return;
+		}
+		if ((jtag_reset_config & RESET_SRST_PULLS_TRST) != 0
+				&& !req_tlr_or_trst) {
+			LOG_ERROR("BUG: can't assert only SRST");
+			jtag_set_error(ERROR_FAIL);
+			return;
+		}
+		new_srst = 1;
+	}
+
+	/* JTAG reset (entry to TAP_RESET state) can always be achieved
+	 * using TCK and TMS; that may go through a TAP_{IR,DR}UPDATE
+	 * state first.  TRST accelerates it, and bypasses those states.
+	 *
+	 * RESET_TRST_PULLS_SRST is a board or chip level quirk, which
+	 * can kick in even if the JTAG adapter can't drive SRST.
+	 */
+	if (req_tlr_or_trst) {
+		if (!(jtag_reset_config & RESET_HAS_TRST))
+			trst_with_tlr = 1;
+		else if ((jtag_reset_config & RESET_TRST_PULLS_SRST) != 0
+			 && !req_srst)
+			trst_with_tlr = 1;
+		else
+			new_trst = 1;
+	}
+
+	/* Maybe change TRST and/or SRST signal state */
+	if (jtag_srst != new_srst || jtag_trst != new_trst) {
+		int retval;
+
+		retval = interface_jtag_add_reset(new_trst, new_srst);
+		if (retval != ERROR_OK)
+			jtag_set_error(retval);
+		else
+			retval = jtag_execute_queue();
+
+		if (retval != ERROR_OK) {
+			LOG_ERROR("TRST/SRST error");
+			return;
+		}
+	}
+
+	/* SRST resets everything hooked up to that signal */
+	if (jtag_srst != new_srst) {
+		jtag_srst = new_srst;
+		if (jtag_srst) {
+			LOG_DEBUG("SRST line asserted");
+			if (adapter_nsrst_assert_width)
+				jtag_add_sleep(adapter_nsrst_assert_width * 1000);
+		} else {
+			LOG_DEBUG("SRST line released");
+			if (adapter_nsrst_delay)
+				jtag_add_sleep(adapter_nsrst_delay * 1000);
+		}
+	}
+
+	/* Maybe enter the JTAG TAP_RESET state ...
+	 *  - using only TMS, TCK, and the JTAG state machine
+	 *  - or else more directly, using TRST
+	 *
+	 * TAP_RESET should be invisible to non-debug parts of the system.
+	 */
+	if (trst_with_tlr) {
+		LOG_DEBUG("JTAG reset with TLR instead of TRST");
+		jtag_add_tlr();
+
+	} else if (jtag_trst != new_trst) {
+		jtag_trst = new_trst;
+		if (jtag_trst) {
+			LOG_DEBUG("TRST line asserted");
+			tap_set_state(TAP_RESET);
+			if (jtag_ntrst_assert_width)
+				jtag_add_sleep(jtag_ntrst_assert_width * 1000);
+		} else {
+			LOG_DEBUG("TRST line released");
+			if (jtag_ntrst_delay)
+				jtag_add_sleep(jtag_ntrst_delay * 1000);
+
+			/* We just asserted nTRST, so we're now in TAP_RESET.
+			 * Inform possible listeners about this, now that
+			 * JTAG instructions and data can be shifted.  This
+			 * sequence must match jtag_add_tlr().
+			 */
+			jtag_call_event_callbacks(JTAG_TRST_ASSERTED);
+			jtag_notify_event(JTAG_TRST_ASSERTED);
+		}
+	}
+}
+
+void jtag_add_sleep(uint32_t us)
+{
+	/** @todo Here, keep_alive() appears to be a layering violation!!! */
+	keep_alive();
+	jtag_set_error(interface_jtag_add_sleep(us));
+}
+
+static int jtag_check_value_inner(uint8_t *captured, uint8_t *in_check_value,
+	uint8_t *in_check_mask, int num_bits)
+{
+	int retval = ERROR_OK;
+	int compare_failed;
+
+	if (in_check_mask)
+		compare_failed = buf_cmp_mask(captured, in_check_value, in_check_mask, num_bits);
+	else
+		compare_failed = buf_cmp(captured, in_check_value, num_bits);
+
+	if (compare_failed) {
+		char *captured_str, *in_check_value_str;
+		int bits = (num_bits > DEBUG_JTAG_IOZ) ? DEBUG_JTAG_IOZ : num_bits;
+
+		/* NOTE:  we've lost diagnostic context here -- 'which tap' */
+
+		captured_str = buf_to_str(captured, bits, 16);
+		in_check_value_str = buf_to_str(in_check_value, bits, 16);
+
+		LOG_WARNING("Bad value '%s' captured during DR or IR scan:",
+			captured_str);
+		LOG_WARNING(" check_value: 0x%s", in_check_value_str);
+
+		free(captured_str);
+		free(in_check_value_str);
+
+		if (in_check_mask) {
+			char *in_check_mask_str;
+
+			in_check_mask_str = buf_to_str(in_check_mask, bits, 16);
+			LOG_WARNING(" check_mask: 0x%s", in_check_mask_str);
+			free(in_check_mask_str);
+		}
+
+		retval = ERROR_JTAG_QUEUE_FAILED;
+	}
+	return retval;
+}
+
+void jtag_check_value_mask(struct scan_field *field, uint8_t *value, uint8_t *mask)
+{
+	assert(field->in_value != NULL);
+
+	if (value == NULL) {
+		/* no checking to do */
+		return;
+	}
+
+	jtag_execute_queue_noclear();
+
+	int retval = jtag_check_value_inner(field->in_value, value, mask, field->num_bits);
+	jtag_set_error(retval);
+}
+
+int default_interface_jtag_execute_queue(void)
+{
+	if (NULL == jtag) {
+		LOG_ERROR("No JTAG interface configured yet.  "
+			"Issue 'init' command in startup scripts "
+			"before communicating with targets.");
+		return ERROR_FAIL;
+	}
+
+	return jtag->execute_queue();
+}
+
+void jtag_execute_queue_noclear(void)
+{
+	jtag_flush_queue_count++;
+	jtag_set_error(interface_jtag_execute_queue());
+
+	if (jtag_flush_queue_sleep > 0) {
+		/* For debug purposes it can be useful to test performance
+		 * or behavior when delaying after flushing the queue,
+		 * e.g. to simulate long roundtrip times.
+		 */
+		usleep(jtag_flush_queue_sleep * 1000);
+	}
+}
+
+int jtag_get_flush_queue_count(void)
+{
+	return jtag_flush_queue_count;
+}
+
+int jtag_execute_queue(void)
+{
+	jtag_execute_queue_noclear();
+	return jtag_error_clear();
+}
+
+static int jtag_reset_callback(enum jtag_event event, void *priv)
+{
+	struct jtag_tap *tap = priv;
+
+	if (event == JTAG_TRST_ASSERTED) {
+		tap->enabled = !tap->disabled_after_reset;
+
+		/* current instruction is either BYPASS or IDCODE */
+		buf_set_ones(tap->cur_instr, tap->ir_length);
+		tap->bypass = 1;
+	}
+
+	return ERROR_OK;
+}
+
+/* sleep at least us microseconds. When we sleep more than 1000ms we
+ * do an alive sleep, i.e. keep GDB alive. Note that we could starve
+ * GDB if we slept for <1000ms many times.
+ */
+void jtag_sleep(uint32_t us)
+{
+	if (us < 1000)
+		usleep(us);
+	else
+		alive_sleep((us+999)/1000);
+}
+
+#define JTAG_MAX_AUTO_TAPS 20
+
+#define EXTRACT_JEP106_BANK(X) (((X) & 0xf00) >> 8)
+#define EXTRACT_JEP106_ID(X)   (((X) & 0xfe) >> 1)
+#define EXTRACT_MFG(X)  (((X) & 0xffe) >> 1)
+#define EXTRACT_PART(X) (((X) & 0xffff000) >> 12)
+#define EXTRACT_VER(X)  (((X) & 0xf0000000) >> 28)
+
+/* A reserved manufacturer ID is used in END_OF_CHAIN_FLAG, so we
+ * know that no valid TAP will have it as an IDCODE value.
+ */
+#define END_OF_CHAIN_FLAG       0xffffffff
+
+/* a larger IR length than we ever expect to autoprobe */
+#define JTAG_IRLEN_MAX          60
+
+static int jtag_examine_chain_execute(uint8_t *idcode_buffer, unsigned num_idcode)
+{
+	struct scan_field field = {
+		.num_bits = num_idcode * 32,
+		.out_value = idcode_buffer,
+		.in_value = idcode_buffer,
+	};
+
+	/* initialize to the end of chain ID value */
+	for (unsigned i = 0; i < num_idcode; i++)
+		buf_set_u32(idcode_buffer, i * 32, 32, END_OF_CHAIN_FLAG);
+
+	jtag_add_plain_dr_scan(field.num_bits, field.out_value, field.in_value, TAP_DRPAUSE);
+	jtag_add_tlr();
+	return jtag_execute_queue();
+}
+
+static bool jtag_examine_chain_check(uint8_t *idcodes, unsigned count)
+{
+	uint8_t zero_check = 0x0;
+	uint8_t one_check = 0xff;
+
+	for (unsigned i = 0; i < count * 4; i++) {
+		zero_check |= idcodes[i];
+		one_check &= idcodes[i];
+	}
+
+	/* if there wasn't a single non-zero bit or if all bits were one,
+	 * the scan is not valid.  We wrote a mix of both values; either
+	 *
+	 *  - There's a hardware issue (almost certainly):
+	 *     + all-zeroes can mean a target stuck in JTAG reset
+	 *     + all-ones tends to mean no target
+	 *  - The scan chain is WAY longer than we can handle, *AND* either
+	 *     + there are several hundreds of TAPs in bypass, or
+	 *     + at least a few dozen TAPs all have an all-ones IDCODE
+	 */
+	if (zero_check == 0x00 || one_check == 0xff) {
+		LOG_ERROR("JTAG scan chain interrogation failed: all %s",
+			(zero_check == 0x00) ? "zeroes" : "ones");
+		LOG_ERROR("Check JTAG interface, timings, target power, etc.");
+		return false;
+	}
+	return true;
+}
+
+static void jtag_examine_chain_display(enum log_levels level, const char *msg,
+	const char *name, uint32_t idcode)
+{
+	log_printf_lf(level, __FILE__, __LINE__, __func__,
+		"JTAG tap: %s %16.16s: 0x%08x "
+		"(mfg: 0x%3.3x (%s), part: 0x%4.4x, ver: 0x%1.1x)",
+		name, msg,
+		(unsigned int)idcode,
+		(unsigned int)EXTRACT_MFG(idcode),
+		jep106_manufacturer(EXTRACT_JEP106_BANK(idcode), EXTRACT_JEP106_ID(idcode)),
+		(unsigned int)EXTRACT_PART(idcode),
+		(unsigned int)EXTRACT_VER(idcode));
+}
+
+static bool jtag_idcode_is_final(uint32_t idcode)
+{
+	/*
+	 * Some devices, such as AVR8, will output all 1's instead
+	 * of TDI input value at end of chain. Allow those values
+	 * instead of failing.
+	 */
+	return idcode == END_OF_CHAIN_FLAG;
+}
+
+/**
+ * This helper checks that remaining bits in the examined chain data are
+ * all as expected, but a single JTAG device requires only 64 bits to be
+ * read back correctly.  This can help identify and diagnose problems
+ * with the JTAG chain earlier, gives more helpful/explicit error messages.
+ * Returns TRUE iff garbage was found.
+ */
+static bool jtag_examine_chain_end(uint8_t *idcodes, unsigned count, unsigned max)
+{
+	bool triggered = false;
+	for (; count < max - 31; count += 32) {
+		uint32_t idcode = buf_get_u32(idcodes, count, 32);
+
+		/* do not trigger the warning if the data looks good */
+		if (jtag_idcode_is_final(idcode))
+			continue;
+		LOG_WARNING("Unexpected idcode after end of chain: %d 0x%08x",
+			count, (unsigned int)idcode);
+		triggered = true;
+	}
+	return triggered;
+}
+
+static bool jtag_examine_chain_match_tap(const struct jtag_tap *tap)
+{
+
+	if (tap->expected_ids_cnt == 0 || !tap->hasidcode)
+		return true;
+
+	/* optionally ignore the JTAG version field - bits 28-31 of IDCODE */
+	uint32_t mask = tap->ignore_version ? ~(0xf << 28) : ~0;
+	uint32_t idcode = tap->idcode & mask;
+
+	/* Loop over the expected identification codes and test for a match */
+	for (unsigned ii = 0; ii < tap->expected_ids_cnt; ii++) {
+		uint32_t expected = tap->expected_ids[ii] & mask;
+
+		if (idcode == expected)
+			return true;
+
+		/* treat "-expected-id 0" as a "don't-warn" wildcard */
+		if (0 == tap->expected_ids[ii])
+			return true;
+	}
+
+	/* If none of the expected ids matched, warn */
+	jtag_examine_chain_display(LOG_LVL_WARNING, "UNEXPECTED",
+		tap->dotted_name, tap->idcode);
+	for (unsigned ii = 0; ii < tap->expected_ids_cnt; ii++) {
+		char msg[32];
+
+		snprintf(msg, sizeof(msg), "expected %u of %u", ii + 1, tap->expected_ids_cnt);
+		jtag_examine_chain_display(LOG_LVL_ERROR, msg,
+			tap->dotted_name, tap->expected_ids[ii]);
+	}
+	return false;
+}
+
+/* Try to examine chain layout according to IEEE 1149.1 �12
+ * This is called a "blind interrogation" of the scan chain.
+ */
+static int jtag_examine_chain(void)
+{
+	int retval;
+	unsigned max_taps = jtag_tap_count();
+
+	/* Autoprobe up to this many. */
+	if (max_taps < JTAG_MAX_AUTO_TAPS)
+		max_taps = JTAG_MAX_AUTO_TAPS;
+
+	/* Add room for end-of-chain marker. */
+	max_taps++;
+
+	uint8_t *idcode_buffer = malloc(max_taps * 4);
+	if (idcode_buffer == NULL)
+		return ERROR_JTAG_INIT_FAILED;
+
+	/* DR scan to collect BYPASS or IDCODE register contents.
+	 * Then make sure the scan data has both ones and zeroes.
+	 */
+	LOG_DEBUG("DR scan interrogation for IDCODE/BYPASS");
+	retval = jtag_examine_chain_execute(idcode_buffer, max_taps);
+	if (retval != ERROR_OK)
+		goto out;
+	if (!jtag_examine_chain_check(idcode_buffer, max_taps)) {
+		retval = ERROR_JTAG_INIT_FAILED;
+		goto out;
+	}
+
+	/* Point at the 1st predefined tap, if any */
+	struct jtag_tap *tap = jtag_tap_next_enabled(NULL);
+
+	unsigned bit_count = 0;
+	unsigned autocount = 0;
+	for (unsigned i = 0; i < max_taps; i++) {
+		assert(bit_count < max_taps * 32);
+		uint32_t idcode = buf_get_u32(idcode_buffer, bit_count, 32);
+
+		/* No predefined TAP? Auto-probe. */
+		if (tap == NULL) {
+			/* Is there another TAP? */
+			if (jtag_idcode_is_final(idcode))
+				break;
+
+			/* Default everything in this TAP except IR length.
+			 *
+			 * REVISIT create a jtag_alloc(chip, tap) routine, and
+			 * share it with jim_newtap_cmd().
+			 */
+			tap = calloc(1, sizeof *tap);
+			if (!tap) {
+				retval = ERROR_FAIL;
+				goto out;
+			}
+
+			tap->chip = alloc_printf("auto%u", autocount++);
+			tap->tapname = strdup("tap");
+			tap->dotted_name = alloc_printf("%s.%s", tap->chip, tap->tapname);
+
+			tap->ir_length = 0; /* ... signifying irlen autoprobe */
+			tap->ir_capture_mask = 0x03;
+			tap->ir_capture_value = 0x01;
+
+			tap->enabled = true;
+
+			jtag_tap_init(tap);
+		}
+
+		if ((idcode & 1) == 0) {
+			/* Zero for LSB indicates a device in bypass */
+			LOG_INFO("TAP %s does not have IDCODE", tap->dotted_name);
+			tap->hasidcode = false;
+			tap->idcode = 0;
+
+			bit_count += 1;
+		} else {
+			/* Friendly devices support IDCODE */
+			tap->hasidcode = true;
+			tap->idcode = idcode;
+			jtag_examine_chain_display(LOG_LVL_INFO, "tap/device found", tap->dotted_name, idcode);
+
+			bit_count += 32;
+		}
+
+		/* ensure the TAP ID matches what was expected */
+		if (!jtag_examine_chain_match_tap(tap))
+			retval = ERROR_JTAG_INIT_SOFT_FAIL;
+
+		tap = jtag_tap_next_enabled(tap);
+	}
+
+	/* After those IDCODE or BYPASS register values should be
+	 * only the data we fed into the scan chain.
+	 */
+	if (jtag_examine_chain_end(idcode_buffer, bit_count, max_taps * 32)) {
+		LOG_ERROR("double-check your JTAG setup (interface, speed, ...)");
+		retval = ERROR_JTAG_INIT_FAILED;
+		goto out;
+	}
+
+	/* Return success or, for backwards compatibility if only
+	 * some IDCODE values mismatched, a soft/continuable fault.
+	 */
+out:
+	free(idcode_buffer);
+	return retval;
+}
+
+/*
+ * Validate the date loaded by entry to the Capture-IR state, to help
+ * find errors related to scan chain configuration (wrong IR lengths)
+ * or communication.
+ *
+ * Entry state can be anything.  On non-error exit, all TAPs are in
+ * bypass mode.  On error exits, the scan chain is reset.
+ */
+static int jtag_validate_ircapture(void)
+{
+	struct jtag_tap *tap;
+	int total_ir_length = 0;
+	uint8_t *ir_test = NULL;
+	struct scan_field field;
+	uint64_t val;
+	int chain_pos = 0;
+	int retval;
+
+	/* when autoprobing, accomodate huge IR lengths */
+	for (tap = NULL, total_ir_length = 0;
+			(tap = jtag_tap_next_enabled(tap)) != NULL;
+			total_ir_length += tap->ir_length) {
+		if (tap->ir_length == 0)
+			total_ir_length += JTAG_IRLEN_MAX;
+	}
+
+	/* increase length to add 2 bit sentinel after scan */
+	total_ir_length += 2;
+
+	ir_test = malloc(DIV_ROUND_UP(total_ir_length, 8));
+	if (ir_test == NULL)
+		return ERROR_FAIL;
+
+	/* after this scan, all TAPs will capture BYPASS instructions */
+	buf_set_ones(ir_test, total_ir_length);
+
+	field.num_bits = total_ir_length;
+	field.out_value = ir_test;
+	field.in_value = ir_test;
+
+	jtag_add_plain_ir_scan(field.num_bits, field.out_value, field.in_value, TAP_IDLE);
+
+	LOG_DEBUG("IR capture validation scan");
+	retval = jtag_execute_queue();
+	if (retval != ERROR_OK)
+		goto done;
+
+	tap = NULL;
+	chain_pos = 0;
+
+	for (;; ) {
+		tap = jtag_tap_next_enabled(tap);
+		if (tap == NULL)
+			break;
+
+		/* If we're autoprobing, guess IR lengths.  They must be at
+		 * least two bits.  Guessing will fail if (a) any TAP does
+		 * not conform to the JTAG spec; or (b) when the upper bits
+		 * captured from some conforming TAP are nonzero.  Or if
+		 * (c) an IR length is longer than JTAG_IRLEN_MAX bits,
+		 * an implementation limit, which could someday be raised.
+		 *
+		 * REVISIT optimization:  if there's a *single* TAP we can
+		 * lift restrictions (a) and (b) by scanning a recognizable
+		 * pattern before the all-ones BYPASS.  Check for where the
+		 * pattern starts in the result, instead of an 0...01 value.
+		 *
+		 * REVISIT alternative approach: escape to some tcl code
+		 * which could provide more knowledge, based on IDCODE; and
+		 * only guess when that has no success.
+		 */
+		if (tap->ir_length == 0) {
+			tap->ir_length = 2;
+			while ((val = buf_get_u64(ir_test, chain_pos, tap->ir_length + 1)) == 1
+					&& tap->ir_length < JTAG_IRLEN_MAX) {
+				tap->ir_length++;
+			}
+			LOG_WARNING("AUTO %s - use \"jtag newtap " "%s %s -irlen %d "
+					"-expected-id 0x%08" PRIx32 "\"",
+					tap->dotted_name, tap->chip, tap->tapname, tap->ir_length, tap->idcode);
+		}
+
+		/* Validate the two LSBs, which must be 01 per JTAG spec.
+		 *
+		 * Or ... more bits could be provided by TAP declaration.
+		 * Plus, some taps (notably in i.MX series chips) violate
+		 * this part of the JTAG spec, so their capture mask/value
+		 * attributes might disable this test.
+		 */
+		val = buf_get_u64(ir_test, chain_pos, tap->ir_length);
+		if ((val & tap->ir_capture_mask) != tap->ir_capture_value) {
+			LOG_ERROR("%s: IR capture error; saw 0x%0*" PRIx64 " not 0x%0*" PRIx32,
+				jtag_tap_name(tap),
+				(tap->ir_length + 7) / tap->ir_length, val,
+				(tap->ir_length + 7) / tap->ir_length, tap->ir_capture_value);
+
+			retval = ERROR_JTAG_INIT_FAILED;
+			goto done;
+		}
+		LOG_DEBUG("%s: IR capture 0x%0*" PRIx64, jtag_tap_name(tap),
+			(tap->ir_length + 7) / tap->ir_length, val);
+		chain_pos += tap->ir_length;
+	}
+
+	/* verify the '11' sentinel we wrote is returned at the end */
+	val = buf_get_u64(ir_test, chain_pos, 2);
+	if (val != 0x3) {
+		char *cbuf = buf_to_str(ir_test, total_ir_length, 16);
+
+		LOG_ERROR("IR capture error at bit %d, saw 0x%s not 0x...3",
+			chain_pos, cbuf);
+		free(cbuf);
+		retval = ERROR_JTAG_INIT_FAILED;
+	}
+
+done:
+	free(ir_test);
+	if (retval != ERROR_OK) {
+		jtag_add_tlr();
+		jtag_execute_queue();
+	}
+	return retval;
+}
+
+void jtag_tap_init(struct jtag_tap *tap)
+{
+	unsigned ir_len_bits;
+	unsigned ir_len_bytes;
+
+	/* if we're autoprobing, cope with potentially huge ir_length */
+	ir_len_bits = tap->ir_length ? : JTAG_IRLEN_MAX;
+	ir_len_bytes = DIV_ROUND_UP(ir_len_bits, 8);
+
+	tap->expected = calloc(1, ir_len_bytes);
+	tap->expected_mask = calloc(1, ir_len_bytes);
+	tap->cur_instr = malloc(ir_len_bytes);
+
+	/** @todo cope better with ir_length bigger than 32 bits */
+	if (ir_len_bits > 32)
+		ir_len_bits = 32;
+
+	buf_set_u32(tap->expected, 0, ir_len_bits, tap->ir_capture_value);
+	buf_set_u32(tap->expected_mask, 0, ir_len_bits, tap->ir_capture_mask);
+
+	/* TAP will be in bypass mode after jtag_validate_ircapture() */
+	tap->bypass = 1;
+	buf_set_ones(tap->cur_instr, tap->ir_length);
+
+	/* register the reset callback for the TAP */
+	jtag_register_event_callback(&jtag_reset_callback, tap);
+	jtag_tap_add(tap);
+
+	LOG_DEBUG("Created Tap: %s @ abs position %d, "
+			"irlen %d, capture: 0x%x mask: 0x%x", tap->dotted_name,
+			tap->abs_chain_position, tap->ir_length,
+			(unsigned) tap->ir_capture_value,
+			(unsigned) tap->ir_capture_mask);
+}
+
+void jtag_tap_free(struct jtag_tap *tap)
+{
+	jtag_unregister_event_callback(&jtag_reset_callback, tap);
+
+	free(tap->expected);
+	free(tap->expected_mask);
+	free(tap->expected_ids);
+	free(tap->cur_instr);
+	free(tap->chip);
+	free(tap->tapname);
+	free(tap->dotted_name);
+	free(tap);
+}
+
+/**
+ * Do low-level setup like initializing registers, output signals,
+ * and clocking.
+ */
+int adapter_init(struct command_context *cmd_ctx)
+{
+	if (jtag)
+		return ERROR_OK;
+
+	if (!jtag_interface) {
+		/* nothing was previously specified by "interface" command */
+		LOG_ERROR("Debug Adapter has to be specified, "
+			"see \"interface\" command");
+		return ERROR_JTAG_INVALID_INTERFACE;
+	}
+
+	int retval;
+	retval = jtag_interface->init();
+	if (retval != ERROR_OK)
+		return retval;
+	jtag = jtag_interface;
+
+	/* LEGACY SUPPORT ... adapter drivers  must declare what
+	 * transports they allow.  Until they all do so, assume
+	 * the legacy drivers are JTAG-only
+	 */
+	if (!transports_are_declared()) {
+		LOG_ERROR("Adapter driver '%s' did not declare "
+			"which transports it allows; assuming "
+			"JTAG-only", jtag->name);
+		retval = allow_transports(cmd_ctx, jtag_only);
+		if (retval != ERROR_OK)
+			return retval;
+	}
+
+	if (jtag->speed == NULL) {
+		LOG_INFO("This adapter doesn't support configurable speed");
+		return ERROR_OK;
+	}
+
+	if (CLOCK_MODE_UNSELECTED == clock_mode) {
+		LOG_ERROR("An adapter speed is not selected in the init script."
+			" Insert a call to adapter_khz or jtag_rclk to proceed.");
+		return ERROR_JTAG_INIT_FAILED;
+	}
+
+	int requested_khz = jtag_get_speed_khz();
+	int actual_khz = requested_khz;
+	int jtag_speed_var = 0;
+	retval = jtag_get_speed(&jtag_speed_var);
+	if (retval != ERROR_OK)
+		return retval;
+	retval = jtag->speed(jtag_speed_var);
+	if (retval != ERROR_OK)
+		return retval;
+	retval = jtag_get_speed_readable(&actual_khz);
+	if (ERROR_OK != retval)
+		LOG_INFO("adapter-specific clock speed value %d", jtag_speed_var);
+	else if (actual_khz) {
+		/* Adaptive clocking -- JTAG-specific */
+		if ((CLOCK_MODE_RCLK == clock_mode)
+				|| ((CLOCK_MODE_KHZ == clock_mode) && !requested_khz)) {
+			LOG_INFO("RCLK (adaptive clock speed) not supported - fallback to %d kHz"
+			, actual_khz);
+		} else
+			LOG_INFO("clock speed %d kHz", actual_khz);
+	} else
+		LOG_INFO("RCLK (adaptive clock speed)");
+
+	return ERROR_OK;
+}
+
+int jtag_init_inner(struct command_context *cmd_ctx)
+{
+	struct jtag_tap *tap;
+	int retval;
+	bool issue_setup = true;
+
+	LOG_DEBUG("Init JTAG chain");
+
+	tap = jtag_tap_next_enabled(NULL);
+	if (tap == NULL) {
+		/* Once JTAG itself is properly set up, and the scan chain
+		 * isn't absurdly large, IDCODE autoprobe should work fine.
+		 *
+		 * But ... IRLEN autoprobe can fail even on systems which
+		 * are fully conformant to JTAG.  Also, JTAG setup can be
+		 * quite finicky on some systems.
+		 *
+		 * REVISIT: if TAP autoprobe works OK, then in many cases
+		 * we could escape to tcl code and set up targets based on
+		 * the TAP's IDCODE values.
+		 */
+		LOG_WARNING("There are no enabled taps.  "
+			"AUTO PROBING MIGHT NOT WORK!!");
+
+		/* REVISIT default clock will often be too fast ... */
+	}
+
+	jtag_add_tlr();
+	retval = jtag_execute_queue();
+	if (retval != ERROR_OK)
+		return retval;
+
+	/* Examine DR values first.  This discovers problems which will
+	 * prevent communication ... hardware issues like TDO stuck, or
+	 * configuring the wrong number of (enabled) TAPs.
+	 */
+	retval = jtag_examine_chain();
+	switch (retval) {
+		case ERROR_OK:
+			/* complete success */
+			break;
+		default:
+			/* For backward compatibility reasons, try coping with
+			 * configuration errors involving only ID mismatches.
+			 * We might be able to talk to the devices.
+			 *
+			 * Also the device might be powered down during startup.
+			 *
+			 * After OpenOCD starts, we can try to power on the device
+			 * and run a reset.
+			 */
+			LOG_ERROR("Trying to use configured scan chain anyway...");
+			issue_setup = false;
+			break;
+	}
+
+	/* Now look at IR values.  Problems here will prevent real
+	 * communication.  They mostly mean that the IR length is
+	 * wrong ... or that the IR capture value is wrong.  (The
+	 * latter is uncommon, but easily worked around:  provide
+	 * ircapture/irmask values during TAP setup.)
+	 */
+	retval = jtag_validate_ircapture();
+	if (retval != ERROR_OK) {
+		/* The target might be powered down. The user
+		 * can power it up and reset it after firing
+		 * up OpenOCD.
+		 */
+		issue_setup = false;
+	}
+
+	if (issue_setup)
+		jtag_notify_event(JTAG_TAP_EVENT_SETUP);
+	else
+		LOG_WARNING("Bypassing JTAG setup events due to errors");
+
+
+	return ERROR_OK;
+}
+
+int adapter_quit(void)
+{
+	if (!jtag || !jtag->quit)
+		return ERROR_OK;
+
+	/* close the JTAG interface */
+	int result = jtag->quit();
+	if (ERROR_OK != result)
+		LOG_ERROR("failed: %d", result);
+
+	return ERROR_OK;
+}
+
+int swd_init_reset(struct command_context *cmd_ctx)
+{
+	int retval = adapter_init(cmd_ctx);
+	if (retval != ERROR_OK)
+		return retval;
+
+	LOG_DEBUG("Initializing with hard SRST reset");
+
+	if (jtag_reset_config & RESET_HAS_SRST)
+		swd_add_reset(1);
+	swd_add_reset(0);
+	retval = jtag_execute_queue();
+	return retval;
+}
+
+int jtag_init_reset(struct command_context *cmd_ctx)
+{
+	int retval = adapter_init(cmd_ctx);
+	if (retval != ERROR_OK)
+		return retval;
+
+	LOG_DEBUG("Initializing with hard TRST+SRST reset");
+
+	/*
+	 * This procedure is used by default when OpenOCD triggers a reset.
+	 * It's now done through an overridable Tcl "init_reset" wrapper.
+	 *
+	 * This started out as a more powerful "get JTAG working" reset than
+	 * jtag_init_inner(), applying TRST because some chips won't activate
+	 * JTAG without a TRST cycle (presumed to be async, though some of
+	 * those chips synchronize JTAG activation using TCK).
+	 *
+	 * But some chips only activate JTAG as part of an SRST cycle; SRST
+	 * got mixed in.  So it became a hard reset routine, which got used
+	 * in more places, and which coped with JTAG reset being forced as
+	 * part of SRST (srst_pulls_trst).
+	 *
+	 * And even more corner cases started to surface:  TRST and/or SRST
+	 * assertion timings matter; some chips need other JTAG operations;
+	 * TRST/SRST sequences can need to be different from these, etc.
+	 *
+	 * Systems should override that wrapper to support system-specific
+	 * requirements that this not-fully-generic code doesn't handle.
+	 *
+	 * REVISIT once Tcl code can read the reset_config modes, this won't
+	 * need to be a C routine at all...
+	 */
+	if (jtag_reset_config & RESET_HAS_SRST) {
+		jtag_add_reset(1, 1);
+		if ((jtag_reset_config & RESET_SRST_PULLS_TRST) == 0)
+			jtag_add_reset(0, 1);
+	} else {
+		jtag_add_reset(1, 0);	/* TAP_RESET, using TMS+TCK or TRST */
+	}
+
+	/* some targets enable us to connect with srst asserted */
+	if (jtag_reset_config & RESET_CNCT_UNDER_SRST) {
+		if (jtag_reset_config & RESET_SRST_NO_GATING)
+			jtag_add_reset(0, 1);
+		else {
+			LOG_WARNING("\'srst_nogate\' reset_config option is required");
+			jtag_add_reset(0, 0);
+		}
+	} else
+		jtag_add_reset(0, 0);
+	retval = jtag_execute_queue();
+	if (retval != ERROR_OK)
+		return retval;
+
+	/* Check that we can communication on the JTAG chain + eventually we want to
+	 * be able to perform enumeration only after OpenOCD has started
+	 * telnet and GDB server
+	 *
+	 * That would allow users to more easily perform any magic they need to before
+	 * reset happens.
+	 */
+	return jtag_init_inner(cmd_ctx);
+}
+
+int jtag_init(struct command_context *cmd_ctx)
+{
+	int retval = adapter_init(cmd_ctx);
+	if (retval != ERROR_OK)
+		return retval;
+
+	/* guard against oddball hardware: force resets to be inactive */
+	jtag_add_reset(0, 0);
+
+	/* some targets enable us to connect with srst asserted */
+	if (jtag_reset_config & RESET_CNCT_UNDER_SRST) {
+		if (jtag_reset_config & RESET_SRST_NO_GATING)
+			jtag_add_reset(0, 1);
+		else
+			LOG_WARNING("\'srst_nogate\' reset_config option is required");
+	}
+	retval = jtag_execute_queue();
+	if (retval != ERROR_OK)
+		return retval;
+
+	if (Jim_Eval_Named(cmd_ctx->interp, "jtag_init", __FILE__, __LINE__) != JIM_OK)
+		return ERROR_FAIL;
+
+	return ERROR_OK;
+}
+
+unsigned jtag_get_speed_khz(void)
+{
+	return speed_khz;
+}
+
+static int adapter_khz_to_speed(unsigned khz, int *speed)
+{
+	LOG_DEBUG("convert khz to interface specific speed value");
+	speed_khz = khz;
+	if (jtag != NULL) {
+		LOG_DEBUG("have interface set up");
+		int speed_div1;
+		int retval = jtag->khz(jtag_get_speed_khz(), &speed_div1);
+		if (ERROR_OK != retval)
+			return retval;
+		*speed = speed_div1;
+	}
+	return ERROR_OK;
+}
+
+static int jtag_rclk_to_speed(unsigned fallback_speed_khz, int *speed)
+{
+	int retval = adapter_khz_to_speed(0, speed);
+	if ((ERROR_OK != retval) && fallback_speed_khz) {
+		LOG_DEBUG("trying fallback speed...");
+		retval = adapter_khz_to_speed(fallback_speed_khz, speed);
+	}
+	return retval;
+}
+
+static int jtag_set_speed(int speed)
+{
+	jtag_speed = speed;
+	/* this command can be called during CONFIG,
+	 * in which case jtag isn't initialized */
+	return jtag ? jtag->speed(speed) : ERROR_OK;
+}
+
+int jtag_config_khz(unsigned khz)
+{
+	LOG_DEBUG("handle jtag khz");
+	clock_mode = CLOCK_MODE_KHZ;
+	int speed = 0;
+	int retval = adapter_khz_to_speed(khz, &speed);
+	return (ERROR_OK != retval) ? retval : jtag_set_speed(speed);
+}
+
+int jtag_config_rclk(unsigned fallback_speed_khz)
+{
+	LOG_DEBUG("handle jtag rclk");
+	clock_mode = CLOCK_MODE_RCLK;
+	rclk_fallback_speed_khz = fallback_speed_khz;
+	int speed = 0;
+	int retval = jtag_rclk_to_speed(fallback_speed_khz, &speed);
+	return (ERROR_OK != retval) ? retval : jtag_set_speed(speed);
+}
+
+int jtag_get_speed(int *speed)
+{
+	switch (clock_mode) {
+		case CLOCK_MODE_KHZ:
+			adapter_khz_to_speed(jtag_get_speed_khz(), speed);
+			break;
+		case CLOCK_MODE_RCLK:
+			jtag_rclk_to_speed(rclk_fallback_speed_khz, speed);
+			break;
+		default:
+			LOG_ERROR("BUG: unknown jtag clock mode");
+			return ERROR_FAIL;
+	}
+	return ERROR_OK;
+}
+
+int jtag_get_speed_readable(int *khz)
+{
+	int jtag_speed_var = 0;
+	int retval = jtag_get_speed(&jtag_speed_var);
+	if (retval != ERROR_OK)
+		return retval;
+	return jtag ? jtag->speed_div(jtag_speed_var, khz) : ERROR_OK;
+}
+
+void jtag_set_verify(bool enable)
+{
+	jtag_verify = enable;
+}
+
+bool jtag_will_verify()
+{
+	return jtag_verify;
+}
+
+void jtag_set_verify_capture_ir(bool enable)
+{
+	jtag_verify_capture_ir = enable;
+}
+
+bool jtag_will_verify_capture_ir()
+{
+	return jtag_verify_capture_ir;
+}
+
+int jtag_power_dropout(int *dropout)
+{
+	if (jtag == NULL) {
+		/* TODO: as the jtag interface is not valid all
+		 * we can do at the moment is exit OpenOCD */
+		LOG_ERROR("No Valid JTAG Interface Configured.");
+		exit(-1);
+	}
+	return jtag->power_dropout(dropout);
+}
+
+int jtag_srst_asserted(int *srst_asserted)
+{
+	return jtag->srst_asserted(srst_asserted);
+}
+
+enum reset_types jtag_get_reset_config(void)
+{
+	return jtag_reset_config;
+}
+void jtag_set_reset_config(enum reset_types type)
+{
+	jtag_reset_config = type;
+}
+
+int jtag_get_trst(void)
+{
+	return jtag_trst;
+}
+int jtag_get_srst(void)
+{
+	return jtag_srst;
+}
+
+void jtag_set_nsrst_delay(unsigned delay)
+{
+	adapter_nsrst_delay = delay;
+}
+unsigned jtag_get_nsrst_delay(void)
+{
+	return adapter_nsrst_delay;
+}
+void jtag_set_ntrst_delay(unsigned delay)
+{
+	jtag_ntrst_delay = delay;
+}
+unsigned jtag_get_ntrst_delay(void)
+{
+	return jtag_ntrst_delay;
+}
+
+
+void jtag_set_nsrst_assert_width(unsigned delay)
+{
+	adapter_nsrst_assert_width = delay;
+}
+unsigned jtag_get_nsrst_assert_width(void)
+{
+	return adapter_nsrst_assert_width;
+}
+void jtag_set_ntrst_assert_width(unsigned delay)
+{
+	jtag_ntrst_assert_width = delay;
+}
+unsigned jtag_get_ntrst_assert_width(void)
+{
+	return jtag_ntrst_assert_width;
+}
+
+static int jtag_select(struct command_context *ctx)
+{
+	int retval;
+
+	/* NOTE:  interface init must already have been done.
+	 * That works with only C code ... no Tcl glue required.
+	 */
+
+	retval = jtag_register_commands(ctx);
+
+	if (retval != ERROR_OK)
+		return retval;
+
+	retval = svf_register_commands(ctx);
+
+	if (retval != ERROR_OK)
+		return retval;
+
+	return xsvf_register_commands(ctx);
+}
+
+static struct transport jtag_transport = {
+	.name = "jtag",
+	.select = jtag_select,
+	.init = jtag_init,
+};
+
+static void jtag_constructor(void) __attribute__((constructor));
+static void jtag_constructor(void)
+{
+	transport_register(&jtag_transport);
+}
+
+/** Returns true if the current debug session
+ * is using JTAG as its transport.
+ */
+bool transport_is_jtag(void)
+{
+	return get_current_transport() == &jtag_transport;
+}
+
+void adapter_assert_reset(void)
+{
+	if (transport_is_jtag()) {
+		if (jtag_reset_config & RESET_SRST_PULLS_TRST)
+			jtag_add_reset(1, 1);
+		else
+			jtag_add_reset(0, 1);
+	} else if (transport_is_swd())
+		swd_add_reset(1);
+	else if (get_current_transport() != NULL)
+		LOG_ERROR("reset is not supported on %s",
+			get_current_transport()->name);
+	else
+		LOG_ERROR("transport is not selected");
+}
+
+void adapter_deassert_reset(void)
+{
+	if (transport_is_jtag())
+		jtag_add_reset(0, 0);
+	else if (transport_is_swd())
+		swd_add_reset(0);
+	else if (get_current_transport() != NULL)
+		LOG_ERROR("reset is not supported on %s",
+			get_current_transport()->name);
+	else
+		LOG_ERROR("transport is not selected");
+}
+
+int adapter_config_trace(bool enabled, enum tpio_pin_protocol pin_protocol,
+			 uint32_t port_size, unsigned int *trace_freq)
+{
+	if (jtag->config_trace)
+		return jtag->config_trace(enabled, pin_protocol, port_size,
+					  trace_freq);
+	else if (enabled) {
+		LOG_ERROR("The selected interface does not support tracing");
+		return ERROR_FAIL;
+	}
+
+	return ERROR_OK;
+}
+
+int adapter_poll_trace(uint8_t *buf, size_t *size)
+{
+	if (jtag->poll_trace)
+		return jtag->poll_trace(buf, size);
+
+	return ERROR_FAIL;
+}

http://git-wip-us.apache.org/repos/asf/incubator-mynewt-site/blob/e302582d/docs/os/tutorials/downloads/openocd-code-89bf96ffe6ac66c80407af8383b9d5adc0dc35f4/src/jtag/driver.h
----------------------------------------------------------------------
diff --git a/docs/os/tutorials/downloads/openocd-code-89bf96ffe6ac66c80407af8383b9d5adc0dc35f4/src/jtag/driver.h b/docs/os/tutorials/downloads/openocd-code-89bf96ffe6ac66c80407af8383b9d5adc0dc35f4/src/jtag/driver.h
new file mode 100755
index 0000000..5a7b4ed
--- /dev/null
+++ b/docs/os/tutorials/downloads/openocd-code-89bf96ffe6ac66c80407af8383b9d5adc0dc35f4/src/jtag/driver.h
@@ -0,0 +1,28 @@
+/***************************************************************************
+ *   Copyright (C) 2005 by Dominic Rath                                    *
+ *   Dominic.Rath@gmx.de                                                   *
+ *                                                                         *
+ *   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 JTAG_DRIVER_H
+#define JTAG_DRIVER_H
+
+struct command_context;
+
+int interface_register_commands(struct command_context *ctx);
+
+#endif /* JTAG_DRIVER_H */

http://git-wip-us.apache.org/repos/asf/incubator-mynewt-site/blob/e302582d/docs/os/tutorials/downloads/openocd-code-89bf96ffe6ac66c80407af8383b9d5adc0dc35f4/src/jtag/drivers/Makefile.am
----------------------------------------------------------------------
diff --git a/docs/os/tutorials/downloads/openocd-code-89bf96ffe6ac66c80407af8383b9d5adc0dc35f4/src/jtag/drivers/Makefile.am b/docs/os/tutorials/downloads/openocd-code-89bf96ffe6ac66c80407af8383b9d5adc0dc35f4/src/jtag/drivers/Makefile.am
new file mode 100755
index 0000000..2aaf8fd
--- /dev/null
+++ b/docs/os/tutorials/downloads/openocd-code-89bf96ffe6ac66c80407af8383b9d5adc0dc35f4/src/jtag/drivers/Makefile.am
@@ -0,0 +1,173 @@
+include $(top_srcdir)/common.mk
+
+noinst_LTLIBRARIES = libocdjtagdrivers.la
+libocdjtagdrivers_la_LIBADD =
+
+libocdjtagdrivers_la_SOURCES = \
+	$(DRIVERFILES)
+
+libocdjtagdrivers_la_CPPFLAGS = $(AM_CPPFLAGS) $(LIBUSB1_CFLAGS) \
+	$(LIBUSB0_CFLAGS) $(HIDAPI_CFLAGS) $(LIBFTDI_CFLAGS)
+
+ULINK_FIRMWARE = $(srcdir)/OpenULINK
+
+EXTRA_DIST = $(ULINK_FIRMWARE) \
+	usb_blaster/README.CheapClone \
+	Makefile.rlink \
+	rlink_call.m4 \
+	rlink_init.m4
+
+DRIVERFILES =
+SUBDIRS=
+
+if JLINK
+if INTERNAL_LIBJAYLINK
+SUBDIRS += libjaylink
+
+libjaylink_internal_la_SOURCES = jlink.c
+libjaylink_internal_la_LIBADD = libjaylink/libjaylink/libjaylink.la
+libjaylink_internal_la_CPPFLAGS = -I$(builddir)/libjaylink/libjaylink \
+	-I$(srcdir)/libjaylink $(AM_CPPFLAGS)
+
+noinst_LTLIBRARIES += libjaylink_internal.la
+libocdjtagdrivers_la_LIBADD += libjaylink_internal.la
+else
+DRIVERFILES += jlink.c
+endif
+endif
+
+# Standard Driver: common files
+DRIVERFILES += driver.c
+
+if USE_LIBUSB1
+DRIVERFILES += libusb1_common.c
+endif
+
+if USE_LIBUSB0
+DRIVERFILES += usb_common.c
+if !USE_LIBUSB1
+DRIVERFILES += libusb0_common.c
+endif
+endif
+
+if BITBANG
+DRIVERFILES += bitbang.c
+endif
+if PARPORT
+DRIVERFILES += parport.c
+endif
+if DUMMY
+DRIVERFILES += dummy.c
+endif
+if FT2232_DRIVER
+DRIVERFILES += ft2232.c
+endif
+if FTDI
+DRIVERFILES += ftdi.c mpsse.c
+endif
+if JTAG_VPI
+DRIVERFILES += jtag_vpi.c
+endif
+if USB_BLASTER_DRIVER
+SUBDIRS += usb_blaster
+libocdjtagdrivers_la_LIBADD += $(top_builddir)/src/jtag/drivers/usb_blaster/libocdusbblaster.la
+endif
+if AMTJTAGACCEL
+DRIVERFILES += amt_jtagaccel.c
+endif
+if EP93XX
+DRIVERFILES += ep93xx.c
+endif
+if AT91RM9200
+DRIVERFILES += at91rm9200.c
+endif
+if GW16012
+DRIVERFILES += gw16012.c
+endif
+if BITQ
+DRIVERFILES += bitq.c
+endif
+if PRESTO_DRIVER
+DRIVERFILES += presto.c
+endif
+if USBPROG
+DRIVERFILES += usbprog.c
+endif
+if RLINK
+DRIVERFILES += rlink.c rlink_speed_table.c
+endif
+if ULINK
+DRIVERFILES += ulink.c
+ulinkdir = $(pkgdatadir)/OpenULINK
+dist_ulink_DATA = $(ULINK_FIRMWARE)/ulink_firmware.hex
+endif
+if VSLLINK
+DRIVERFILES += versaloon/usbtoxxx/usbtogpio.c
+DRIVERFILES += versaloon/usbtoxxx/usbtojtagraw.c
+DRIVERFILES += versaloon/usbtoxxx/usbtoswd.c
+DRIVERFILES += versaloon/usbtoxxx/usbtopwr.c
+DRIVERFILES += versaloon/usbtoxxx/usbtoxxx.c
+DRIVERFILES += versaloon/versaloon.c
+DRIVERFILES += vsllink.c
+endif
+if ARMJTAGEW
+DRIVERFILES += arm-jtag-ew.c
+endif
+if BUSPIRATE
+DRIVERFILES += buspirate.c
+endif
+if REMOTE_BITBANG
+DRIVERFILES += remote_bitbang.c
+endif
+if HLADAPTER
+DRIVERFILES += stlink_usb.c
+DRIVERFILES += ti_icdi_usb.c
+endif
+if OSBDM
+DRIVERFILES += osbdm.c
+endif
+if OPENDOUS
+DRIVERFILES += opendous.c
+endif
+if SYSFSGPIO
+DRIVERFILES += sysfsgpio.c
+endif
+if BCM2835GPIO
+DRIVERFILES += bcm2835gpio.c
+endif
+
+if OPENJTAG
+DRIVERFILES += openjtag.c
+endif
+
+if CMSIS_DAP
+DRIVERFILES += cmsis_dap_usb.c
+endif
+
+noinst_HEADERS = \
+	bitbang.h \
+	bitq.h \
+	ftd2xx_common.h \
+	libusb0_common.h \
+	libusb1_common.h \
+	libusb_common.h \
+	minidriver_imp.h \
+	mpsse.h \
+	rlink.h \
+	rlink_dtc_cmd.h \
+	rlink_ep1_cmd.h \
+	rlink_st7.h \
+	usb_common.h \
+	versaloon/usbtoxxx/usbtoxxx.h \
+	versaloon/usbtoxxx/usbtoxxx_internal.h \
+	versaloon/versaloon.h \
+	versaloon/versaloon_include.h \
+	versaloon/versaloon_internal.h
+
+DIST_SUBDIRS = usb_blaster
+
+if INTERNAL_LIBJAYLINK
+DIST_SUBDIRS += libjaylink
+endif
+
+MAINTAINERCLEANFILES = $(srcdir)/Makefile.in

http://git-wip-us.apache.org/repos/asf/incubator-mynewt-site/blob/e302582d/docs/os/tutorials/downloads/openocd-code-89bf96ffe6ac66c80407af8383b9d5adc0dc35f4/src/jtag/drivers/Makefile.rlink
----------------------------------------------------------------------
diff --git a/docs/os/tutorials/downloads/openocd-code-89bf96ffe6ac66c80407af8383b9d5adc0dc35f4/src/jtag/drivers/Makefile.rlink b/docs/os/tutorials/downloads/openocd-code-89bf96ffe6ac66c80407af8383b9d5adc0dc35f4/src/jtag/drivers/Makefile.rlink
new file mode 100755
index 0000000..6a7638e
--- /dev/null
+++ b/docs/os/tutorials/downloads/openocd-code-89bf96ffe6ac66c80407af8383b9d5adc0dc35f4/src/jtag/drivers/Makefile.rlink
@@ -0,0 +1,73 @@
+#***************************************************************************
+#*   Copyright (C) 2008 Lou Deluxe                                         *
+#*   lou.openocd012@fixit.nospammail.net                                   *
+#*                                                                         *
+#*   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.           *
+#***************************************************************************
+
+TOP = ../../..
+INTERFACE_NAME = rlink
+
+PERL = perl
+M4 = m4
+
+TARGETDIR = ${TOP}/src/target
+TOOLSDIR = ${TOP}/tools
+
+MAKE_SPEED_TABLE = ${TOOLSDIR}/rlink_make_speed_table/rlink_make_speed_table
+ST7_DTC_AS = ${TOOLSDIR}/st7_dtc_as/st7_dtc_as
+
+OPENOCD = ${TOP}/src/openocd
+OPENOCD_CONFIG = -s ${TARGETDIR}
+OPENOCD_CONFIG += -f interface/rlink.cfg
+OPENOCD_CONFIG += -f board/stm32f10x_128k_eval.cfg
+
+PATCHFILE = /tmp/openocd_${INTERFACE_NAME}.diff.gz
+
+# relative to ${TOP}
+SVNADDFILES =
+SVNADDFILES += src/target/interface/rlink.cfg
+SVNADDFILES += src/jtag/${INTERFACE_NAME}.c
+SVNADDFILES += src/jtag/${INTERFACE_NAME}
+
+PRESCALERS = 64 11 8 2
+
+DTCFILES =
+DTCFILES += $(addsuffix _init.dtc, ${PRESCALERS})
+DTCFILES += $(addsuffix _call.dtc, ${PRESCALERS})
+
+default: rlink_speed_table.c clean
+
+%_init.fsm: rlink_init.m4
+	${M4} -P -DSHIFTER_PRESCALER=`echo "$@" | sed -e's/_.*//'` $< > $@
+
+%_call.fsm: rlink_call.m4
+	${M4} -P -DSHIFTER_PRESCALER=`echo "$@" | sed -e's/_.*//'` $< > $@
+
+%.dtc: %.fsm
+	${ST7_DTC_AS} -b -o $@ -i $< > /dev/null
+
+rlink_speed_table.c: ${DTCFILES}
+	${MAKE_SPEED_TABLE} ${PRESCALERS} > $@ || rm $@
+
+clean:
+	-rm *.dtc *.fsm
+
+distclean: clean
+
+test: default
+	(cd ${TOP} && (rm src/jtag/${INTERFACE_NAME}.o; ${MAKE}))
+	${OPENOCD} -d0 ${OPENOCD_CONFIG} -c init -c 'poll off'

http://git-wip-us.apache.org/repos/asf/incubator-mynewt-site/blob/e302582d/docs/os/tutorials/downloads/openocd-code-89bf96ffe6ac66c80407af8383b9d5adc0dc35f4/src/jtag/drivers/OpenULINK/README
----------------------------------------------------------------------
diff --git a/docs/os/tutorials/downloads/openocd-code-89bf96ffe6ac66c80407af8383b9d5adc0dc35f4/src/jtag/drivers/OpenULINK/README b/docs/os/tutorials/downloads/openocd-code-89bf96ffe6ac66c80407af8383b9d5adc0dc35f4/src/jtag/drivers/OpenULINK/README
new file mode 100755
index 0000000..445d770
--- /dev/null
+++ b/docs/os/tutorials/downloads/openocd-code-89bf96ffe6ac66c80407af8383b9d5adc0dc35f4/src/jtag/drivers/OpenULINK/README
@@ -0,0 +1,34 @@
+This is the OpenULINK firmware for the Keil ULINK JTAG adapter.
+
+The main components of the Keil ULINK adapter are:
+- Cypress EZ-USB microcontroller: enhanced 8051 CPU + USB core (1.1 Full-Speed)
+- SRAM memory chip
+- Level shifters to support different JTAG signal voltage levels
+- Pin headers for various JTAG pin assignments
+
+This firmware can only be run on the ORIGINAL Keil ULINK adapter, not on the
+newer ULINK2, ULINK-ME or ULINK-PRO, as these adapters are based on different
+hardware.
+
+To compile the firmware, the SDCC compiler package is required. Most Linux
+distributions include SDCC in their official package repositories. The SDCC
+source code can be found at http://sdcc.sourceforge.net/
+Simply type "make hex" in the OpenULINK directory to compile the firmware.
+"make clean" will remove all generated files except the Intel HEX file required
+for downloading the firmware to the ULINK adapter.
+
+Note that the EZ-USB microcontroller does not have on-chip flash, nor does the
+Keil ULINK include on-board memory to store the firmware program of the EZ-USB.
+Instead, upon initial connection of the ULINK adapter to the host PC via USB,
+the EZ-USB core has enough intelligence to act as a stand-alone USB device,
+responding to USB control requests and allowing firmware download via a special
+VENDOR-type control request. Then, the EZ-USB microcontroller simulates a
+disconnect and re-connect to the USB bus. It may take up to two seconds for the
+host to recognize the newly connected device before OpenOCD can proceed to
+execute JTAG commands. This delay is only visible when OpenOCD first uses a
+blank (unconfigured) ULINK device.
+
+Once the user disconnects the ULINK adapter, all its memory contents are lost
+and the firmware download process has to be executed again. This also maintains
+compatibility with the original Keil uVision IDE, which will happily download
+its own firmware image to a blank ULINK adapter.

http://git-wip-us.apache.org/repos/asf/incubator-mynewt-site/blob/e302582d/docs/os/tutorials/downloads/openocd-code-89bf96ffe6ac66c80407af8383b9d5adc0dc35f4/src/jtag/drivers/OpenULINK/include/common.h
----------------------------------------------------------------------
diff --git a/docs/os/tutorials/downloads/openocd-code-89bf96ffe6ac66c80407af8383b9d5adc0dc35f4/src/jtag/drivers/OpenULINK/include/common.h b/docs/os/tutorials/downloads/openocd-code-89bf96ffe6ac66c80407af8383b9d5adc0dc35f4/src/jtag/drivers/OpenULINK/include/common.h
new file mode 100755
index 0000000..b4f6df9
--- /dev/null
+++ b/docs/os/tutorials/downloads/openocd-code-89bf96ffe6ac66c80407af8383b9d5adc0dc35f4/src/jtag/drivers/OpenULINK/include/common.h
@@ -0,0 +1,26 @@
+/***************************************************************************
+ *   Copyright (C) 2011 by Martin Schmoelzer                               *
+ *   <ma...@student.tuwien.ac.at>                              *
+ *                                                                         *
+ *   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 __COMMON_H
+#define __COMMON_H
+
+#define DIV_ROUND_UP(m, n)  (((m) + (n) - 1) / (n))
+
+#endif