You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@mynewt.apache.org by GitBox <gi...@apache.org> on 2018/03/03 00:31:30 UTC

[GitHub] aditihilbert closed pull request #407: automated asf-site build

aditihilbert closed pull request #407: automated asf-site build
URL: https://github.com/apache/mynewt-site/pull/407
 
 
   

This is a PR merged from a forked repository.
As GitHub hides the original diff on merge, it is displayed below for
the sake of provenance:

As this is a foreign pull request (from a fork), the diff is supplied
below (as it won't show otherwise due to GitHub magic):

diff --git a/develop/_sources/misc/faq.rst.txt b/develop/_sources/misc/faq.rst.txt
index be4131524..a37ac829a 100644
--- a/develop/_sources/misc/faq.rst.txt
+++ b/develop/_sources/misc/faq.rst.txt
@@ -13,7 +13,7 @@ Mynewt software questions:
 How do I reduce the code size for my Mynewt image?
 ~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~
 
-Please refer to the tutorial documentation on `reducing application code size <https://github.com/apache/mynewt-site/blob/master/docs/os/tutorials/codesize.md>`_.
+Please refer to the tutorial documentation on :doc:`reducing application code size <../tutorials/other/codesize>`.
 
 I'm having issues using Newt Manager with the Adafruit nRF52DK. What do I do?
 ~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~
diff --git a/develop/_sources/os/core_os/API.rst.txt b/develop/_sources/os/core_os/API.rst.txt
deleted file mode 100644
index 3a5a05f30..000000000
--- a/develop/_sources/os/core_os/API.rst.txt
+++ /dev/null
@@ -1,33 +0,0 @@
-Core OS API
------------
-
-.. contents::
-  :local:
-  :depth: 2
-
-
-Core
-~~~~
-
-.. doxygenfile:: os.h
-
-
-Scheduler
-~~~~~~~~~
-
-.. doxygenfile:: os_sched.h
-
-CPU Time
-~~~~~~~~
-
-.. doxygenfile:: os_cputime.h
-
-OS Time
-~~~~~~~~
-
-.. doxygenfile:: os_time.h
-
-Task
-~~~~
-
-.. doxygenfile:: os_task.h
diff --git a/develop/_sources/os/core_os/callout/callout.rst.txt b/develop/_sources/os/core_os/callout/callout.rst.txt
index ad8f51d29..c52dc371a 100644
--- a/develop/_sources/os/core_os/callout/callout.rst.txt
+++ b/develop/_sources/os/core_os/callout/callout.rst.txt
@@ -1,7 +1,7 @@
 Callout
 =======
 
-Callouts are MyNewt OS timers.
+Callouts are Apache Mynewt OS timers.
 
 Description
 ~~~~~~~~~~~
@@ -10,73 +10,33 @@ Callout is a way of setting up an OS timer. When the timer fires, it is
 delivered as an event to task's event queue.
 
 User would initialize their callout structure using
-*os\_callout\_init()*, or *os\_callout\_func\_init()* and then arm it
-with *os\_callout\_reset()*.
+:c:func:`os_callout_init()`, or :c:func:`os_callout_func_init()` and 
+then arm it with :c:func:`os_callout_reset()`.
 
 If user wants to cancel the timer before it expires, they can either use
-*os\_callout\_reset()* to arm it for later expiry, or stop it altogether
-by calling *os\_callout\_stop()*.
+:c:func:`os_callout_reset()` to arm it for later expiry, or stop it altogether
+by calling :c:func:`os_callout_stop()`.
 
 There are 2 different options for data structure to use. First is
-*struct os\_callout*, which is a bare-bones version. You would
-initialize this with *os\_callout\_init()*.
+:c:type:`struct os_callout`, which is a bare-bones version. You would
+initialize this with :c:func:`os_callout_init()`.
 
-Second option is *struct os\_callout\_func*. This you can use if you
+Second option is :c:type:`struct os_callout_func`. This you can use if you
 expect to have multiple different types of timers in your task, running
 concurrently. The structure contains a function pointer, and you would
 call that function from your task's event processing loop.
 
 Time unit when arming the timer is OS ticks. This rate of this ticker
 depends on the platform this is running on. You should use OS define
-*OS\_TICKS\_PER\_SEC* to convert wallclock time to OS ticks.
+``OS_TICKS_PER_SEC`` to convert wallclock time to OS ticks.
 
 Callout timer fires out just once. For periodic timer type of operation
 you need to rearm it once it fires.
 
-Data structures
-~~~~~~~~~~~~~~~
-
-::
-
-    struct os_callout {
-        struct os_event c_ev;
-        struct os_eventq *c_evq;
-        uint32_t c_ticks;
-        TAILQ_ENTRY(os_callout) c_next;
-    };
-
-+------------+------------------------------------------------------------+
-| Element    | Description                                                |
-+============+============================================================+
-| c\_ev      | Event structure of this callout                            |
-+------------+------------------------------------------------------------+
-| c\_evq     | Event queue where this callout is placed on timer expiry   |
-+------------+------------------------------------------------------------+
-| c\_ticks   | OS tick amount when timer fires                            |
-+------------+------------------------------------------------------------+
-| c\_next    | Linkage to other unexpired callouts                        |
-+------------+------------------------------------------------------------+
-
-::
-
-    struct os_callout_func {
-        struct os_callout cf_c;
-        os_callout_func_t cf_func;
-        void *cf_arg;
-    };
-
-+------------+---------------------------------------------------------------------+
-| Element    | Description                                                         |
-+============+=====================================================================+
-| cf\_c      | struct os\_callout. See above                                       |
-+------------+---------------------------------------------------------------------+
-| cf\_func   | Function pointer which should be called by event queue processing   |
-+------------+---------------------------------------------------------------------+
-| cf\_arg    | Generic void \* argument to that function                           |
-+------------+---------------------------------------------------------------------+
 
 API
 -----------------
 
 .. doxygengroup:: OSCallouts
     :content-only:
+    :members:
diff --git a/develop/_sources/os/core_os/context_switch/context_switch.rst.txt b/develop/_sources/os/core_os/context_switch/context_switch.rst.txt
index f3ff7430c..3c8c5dcbc 100644
--- a/develop/_sources/os/core_os/context_switch/context_switch.rst.txt
+++ b/develop/_sources/os/core_os/context_switch/context_switch.rst.txt
@@ -5,7 +5,7 @@ Scheduler's job is to maintain the list of tasks and decide which one
 should be running next.
 
 Description
-***********
+-------------
 
 Task states can be *running*, *ready to run* or *sleeping*.
 
@@ -20,7 +20,7 @@ someone else to wake it up.
 
 Scheduler algorithm is simple: from among the tasks which are ready to
 run, pick the the one with highest priority (lowest numeric value in
-task's t\_prio field), and make its state *running*.
+task's :c:member:`t_prio` field), and make its state *running*.
 
 Tasks which are either *running* or *ready to run* are kept in linked
 list ``g_os_run_list``. This list is ordered by priority.
@@ -34,17 +34,8 @@ the CPU (e.g. registers) for the currently *running* task is stored and
 the new task is swapped in.
 
 API
-***
-
-* :c:func:`os_sched()`
-* :c:func:`os_arch_ctx_sw()`
-* :c:func:`os_sched_ctx_sw_hook()`
-* :c:func:`os_sched_get_current_task()`
-* :c:func:`os_sched_insert()`
-* :c:func:`os_sched_next_task()`
-* :c:func:`os_sched_os_timer_exp()`
-* :c:func:`os_sched_remove()`
-* :c:func:`os_sched_resort()`
-* :c:func:`os_sched_set_current_task()`
-* :c:func:`os_sched_sleep()`
-* :c:func:`os_sched_wakeup()`
+----
+
+.. doxygengroup:: OSSched
+    :content-only:
+    :members:
diff --git a/develop/_sources/os/core_os/cputime/os_cputime.rst.txt b/develop/_sources/os/core_os/cputime/os_cputime.rst.txt
index 1304b0189..cf0c2e000 100644
--- a/develop/_sources/os/core_os/cputime/os_cputime.rst.txt
+++ b/develop/_sources/os/core_os/cputime/os_cputime.rst.txt
@@ -8,38 +8,15 @@ Description
 -----------
 
 The ``cputime`` API provides high resolution time and timer support. The
-module must be initialized, using the ``os_cputime_init()`` function,
+module must be initialized, using the :c:func:`os_cputime_init()` function,
 with the clock frequency to use. The module uses the ``hal_timer`` API,
 defined in hal/hal_timer.h, to access the hardware timers. It uses the
 hardware timer number specified by the ``OS_CPUTIME_TIMER_NUM`` system
 configuration setting.
 
-Data Structures
----------------
-
-The module uses the following data structures:
-
--  ``uint32_t`` to represent ``cputime``. Only the lower 32 bits of a 64
-   timer are used.
--  ``struct hal_timer`` to represent a cputime timer.
-
 API
 -----------------
 
-* :c:func:`os_cputime_delay_nsecs()`
-* :c:func:`os_cputime_delay_ticks()`
-* :c:func:`os_cputime_delay_usecs()`
-* :c:func:`os_cputime_get32()`
-* :c:func:`os_cputime_init()`
-* :c:func:`os_cputime_nsecs_to_ticks()`
-* :c:func:`os_cputime_ticks_to_nsecs()`
-* :c:func:`os_cputime_ticks_to_usecs()`
-* :c:func:`os_cputime_timer_init()`
-* :c:func:`os_cputime_timer_relative()`
-* :c:func:`os_cputime_timer_start()`
-* :c:func:`os_cputime_timer_stop()`
-* :c:func:`os_cputime_usecs_to_ticks()`
-* :c:macro:`CPUTIME_LT`
-* :c:macro:`CPUTIME_GT`
-* :c:macro:`CPUTIME_LEQ`
-* :c:macro:`CPUTIME_GEQ`
+.. doxygengroup:: OSCPUTime
+    :content-only:
+    :members:
diff --git a/develop/_sources/os/core_os/event_queue/event_queue.rst.txt b/develop/_sources/os/core_os/event_queue/event_queue.rst.txt
index b8f2f7606..8c2aabcf7 100644
--- a/develop/_sources/os/core_os/event_queue/event_queue.rst.txt
+++ b/develop/_sources/os/core_os/event_queue/event_queue.rst.txt
@@ -4,9 +4,8 @@ Event Queues
 An event queue allows a task to serialize incoming events and simplify
 event processing. Events are stored in a queue and a task removes and
 processes an event from the queue. An event is processed in the context
-of this task. Events may be generated by `OS
-callouts <../callout/callout.html>`__, interrupt handlers, and other
-tasks.
+of this task. Events may be generated by OS callouts, interrupt handlers, 
+and other tasks.
 
 Description
 ---------------
@@ -30,83 +29,36 @@ real-time timing requirements should use Mynewt's default event queue
 for its events. The callback function for an event from the Mynewt
 default event queue is executed in the context of the application main
 task. A package can, optionally, export a function that allows an
-application to specify the event queue for the package to use. (See the
-example in the ``os_eventq_designate()`` function description on how to
-write such a function.) The application task handler that manages the
-event queue simply pulls events from the event queue and executes the
-event's callback function in its context.
+application to specify the event queue for the package to use. The 
+application task handler that manages the event queue simply pulls events 
+from the event queue and executes the event's callback function in its context.
 
 A common way that Mynewt applications or packages process events from an
 event queue is to have a task that executes in an infinite loop and
-calls the ``os_eventq_get()`` function to dequeue and return the event
+calls the :c:func:`os_eventq_get()` function to dequeue and return the event
 from the head of the event queue. The task then calls the event callback
-function to process the event. The ``os_eventq_get()`` function puts the
+function to process the event. The :c:func:`os_eventq_get()` function puts the
 task in to the ``sleeping`` state when there are no events on the queue.
-(See `Scheduler <../context_switch/context_switch.html>`__ for more
+(See :doc:`../context_switch/context_switch` for more
 information on task execution states.) Other tasks (or interrupts) call
-the ``os_eventq_put()`` function to add an event to the queue. The
-``os_eventq_put()`` function determines whether a task is blocked
+the :c:func:`os_eventq_put()` function to add an event to the queue. The
+:c:func:`os_eventq_put()` function determines whether a task is blocked
 waiting for an event on the queue and puts the task into the
 ``ready-to-run`` state.
 
-A task can use the ``os_eventq_run()`` wrapper function that calls the
-``os_eventq_get()`` function to dequeue an event from the queue and then
+A task can use the :c:func:`os_eventq_run()` wrapper function that calls the
+:c:func:`os_eventq_get()` function to dequeue an event from the queue and then
 calls the event callback function to process the event.
-
 Note:
 
 -  Only one task should consume or block waiting for events from an
    event queue.
--  The `os\_callout <../callout/callout.html>`__ subsystem uses events for
-   timer expiration notification.
-
-Data structures
----------------
-
-The ``os_event`` structure defines an event and has the following
-fields:
-
-.. code:: c
-
-    struct os_event {
-        uint8_t ev_queued;
-        os_event_fn *ev_cb;
-        void *ev_arg;
-        STAILQ_ENTRY(os_event) ev_next;
-    };
-
-+-----------------+--------------------------------------------------------------------------------------------+
-| Element         | Description                                                                                |
-+=================+============================================================================================+
-| ``ev_queued``   | Internal field that indicates whether this event is currently linked to an event queue     |
-+-----------------+--------------------------------------------------------------------------------------------+
-| ``ev_cb``       | Pointer to the callback function to call to process this event                             |
-+-----------------+--------------------------------------------------------------------------------------------+
-| ``ev_arg``      | Pointer to an optional opaque data that the callback function uses to process this event   |
-+-----------------+--------------------------------------------------------------------------------------------+
-| ``ev_next``     | Linkage attaching this event to an event queue                                             |
-+-----------------+--------------------------------------------------------------------------------------------+
-
-An event callback function has the following function prototype:
-
-.. code:: c
+-  The OS callout subsystem uses events for timer expiration notification.
 
-    typedef void os_event_fn(struct os_event *ev);
+Example
+-------
 
-A pointer to the ``os_event`` structure for the event is passed as an
-argument to the callback function.
-
-Notes: If the memory for the ``os_event`` structure is dynamically
-allocated:
-
--  You must not free the memory for an event that is currently on an
-   event queue.
--  You must free the memory in the callback function after it completes
-   processing the event.
-
-You must set the callback function for an event when you initialize the
-event. For example, here is an example of a statically-initialized event
-in the NimBLE host:
+Here is an example of using an event from the BLE host: 
 
 .. code:: c
 
@@ -117,29 +69,10 @@ in the NimBLE host:
         .ev_cb = ble_hs_event_tx_notify,
     };
 
-The ``os_eventq`` structure defines an event queue and has the following fields:
-
-.. code:: c
-
-    struct os_eventq {
-        struct os_task *evq_task;
-        STAILQ_HEAD(, os_event) evq_list;
-    };
-
-+----------------+------------------------------------------------------------------------------------------------------------------------------------+
-| Element        | Description                                                                                                                        |
-+================+====================================================================================================================================+
-| ``evq_task``   | Pointer to the task, if any, that is waiting (in the ``sleeping`` state) for the ``os_eventq_get()`` function to return an event   |
-+----------------+------------------------------------------------------------------------------------------------------------------------------------+
-| ``evq_list``   | Head of the list of events in this queue                                                                                           |
-+----------------+------------------------------------------------------------------------------------------------------------------------------------+
-
-
-You must call the ``os_eventq_init()`` function to initialize an event
-queue before you can add events to the queue.
-
+    
 API
 ----
 
 .. doxygengroup:: OSEvent
+    :members:
     :content-only:
diff --git a/develop/_sources/os/core_os/heap/heap.rst.txt b/develop/_sources/os/core_os/heap/heap.rst.txt
index c4e30b2ab..9915da0b9 100644
--- a/develop/_sources/os/core_os/heap/heap.rst.txt
+++ b/develop/_sources/os/core_os/heap/heap.rst.txt
@@ -8,18 +8,13 @@ Description
 
 This provides malloc()/free() functionality with locking. The shared
 resource heap needs to be protected from concurrent access when OS has
-been started. *os\_malloc()* function grabs a mutex before calling
-*malloc()*.
+been started. :c:func:`os_malloc()` function grabs a mutex before calling
+``malloc()``.
 
-Data structures
------------------
-
-N/A
 
 API
 ----
 
-See the API for OS level function calls.
-
--  `Mynewt Core OS <../mynewt_os.html>`__
-
+.. doxygengroup:: OSMalloc
+    :content-only:
+    :members:
diff --git a/develop/_sources/os/core_os/mbuf/mbuf.rst.txt b/develop/_sources/os/core_os/mbuf/mbuf.rst.txt
index e5df9f573..b1e775075 100644
--- a/develop/_sources/os/core_os/mbuf/mbuf.rst.txt
+++ b/develop/_sources/os/core_os/mbuf/mbuf.rst.txt
@@ -40,7 +40,7 @@ various layers of the networking stack. Any mbufs that are part of the
 packet (i.e. in the mbuf chain but not the first one) are "normal" (i.e.
 non-packet header) mbufs. A normal mbuf does not have any packet header
 or user packet header structures in them; they only contain the basic
-mbuf header (``struct os_mbuf``). Figure 1 illustrates these two types
+mbuf header (:c:type:`struct os_mbuf`). Figure 1 illustrates these two types
 of mbufs. Note that the numbers/text in parentheses denote the size of
 the structures/elements (in bytes) and that MBLEN is the memory block
 length of the memory pool used by the mbuf pool.
@@ -55,35 +55,35 @@ Normal mbuf
 
 Now let's take a deeper dive into the mbuf structure. Figure 2
 illustrates a normal mbuf and breaks out the various fields in the
-``os_mbuf`` structure.
+c:type:`os_mbuf` structure.
 
--  The *om\_data* field is a pointer to where the data starts inside the
+-  The :c:member:`om_data` field is a pointer to where the data starts inside the
    data buffer. Typically, mbufs that are allocated from the mbuf pool
-   (discussed later) have their om\_data pointer set to the start of the
+   (discussed later) have their :c:member:`om_data` pointer set to the start of the
    data buffer but there are cases where this may not be desirable
    (added a protocol header to a packet, for example).
--  The *om\_flags* field is a set of flags used internally by the mbuf
+-  The :c:member:`om_flags` field is a set of flags used internally by the mbuf
    library. Currently, no flags have been defined.
--  The *om\_pkthdr\_len* field is the total length of all packet headers
+-  The :c:member:`om_pkthdr_len` field is the total length of all packet headers
    in the mbuf. For normal mbufs this is set to 0 as there is no packet
    or user packet headers. For packet header mbufs, this would be set to
    the length of the packet header structure (16) plus the size of the
    user packet header (if any). Note that it is this field which
    differentiates packet header mbufs from normal mbufs (i.e. if
-   *om\_pkthdr\_len* is zero, this is a normal mbuf; otherwise it is a
+   :c:member:`om_pkthdr_len` is zero, this is a normal mbuf; otherwise it is a
    packet header mbuf).
--  The *om\_len* field contains the amount of user data in the data
+-  The :c:member:`om_len` field contains the amount of user data in the data
    buffer. When initially allocated, this field is 0 as there is no user
    data in the mbuf.
--  The *omp\_pool* field is a pointer to the pool from which this mbuf
+-  The :c:member:`omp_pool` field is a pointer to the pool from which this mbuf
    has been allocated. This is used internally by the mbuf library.
--  The *omp\_next* field is a linked list element which is used to chain
+-  The :c:member:`omp_next` field is a linked list element which is used to chain
    mbufs.
 
-Figure 2 also shows a normal mbuf with actual values in the ``os_mbuf``
+Figure 2 also shows a normal mbuf with actual values in the :c:type:`os_mbuf`
 structure. This mbuf starts at address 0x1000 and is 256 bytes in total
 length. In this example, the user has copied 33 bytes into the data
-buffer starting at address 0x1010 (this is where om\_data points). Note
+buffer starting at address 0x1010 (this is where :c:member:`om_data` points). Note
 that the packet header length in this mbuf is 0 as it is not a packet
 header mbuf.
 
@@ -95,7 +95,7 @@ header mbuf.
 Figure 3 illustrates the packet header mbuf along with some chained
 mbufs (i.e a "packet"). In this example, the user header structure is
 defined to be 8 bytes. Note that in figure 3 we show a number of
-different mbufs with varying *om\_data* pointers and lengths since we
+different mbufs with varying :c:member:`om_data` pointers and lengths since we
 want to show various examples of valid mbufs. For all the mbufs (both
 packet header and normal ones) the total length of the memory block is
 128 bytes.
@@ -172,18 +172,54 @@ block size required, denoted by the macro *MBUF\_MEMBLOCK\_OVERHEAD*.
         assert(rc == 0);
     }
 
+Msys
+-----
+
+Msys stands for "system mbufs" and is a set of API built on top of the
+mbuf code. The basic idea behind msys is the following. The developer
+can create different size mbuf pools and register them with msys. The
+application then allocates mbufs using the msys API (as opposed to the
+mbuf API). The msys code will choose the mbuf pool with the smallest
+mbufs that can accommodate the requested size.
+
+Let us walk through an example where the user registers three mbuf pools
+with msys: one with 32 byte mbufs, one with 256 and one with 2048. If
+the user requests an mbuf with 10 bytes, the 32-byte mbuf pool is used.
+If the request is for 33 bytes the 256 byte mbuf pool is used. If an
+mbuf data size is requested that is larger than any of the pools (say,
+4000 bytes) the largest pool is used. While this behaviour may not be
+optimal in all cases that is the currently implemented behaviour. All
+this means is that the user is not guaranteed that a single mbuf can
+hold the requested data.
+
+The msys code will not allocate an mbuf from a larger pool if the chosen
+mbuf pool is empty. Similarly, the msys code will not chain together a
+number of smaller mbufs to accommodate the requested size. While this
+behaviour may change in future implementations the current code will
+simply return NULL. Using the above example, say the user requests 250
+bytes. The msys code chooses the appropriate pool (i.e. the 256 byte
+mbuf pool) and attempts to allocate an mbuf from that pool. If that pool
+is empty, NULL is returned even though the 32 and 2048 byte pools are
+not empty.
+
+Note that no added descriptions on how to use the msys API are presented
+here (other than in the API descriptions themselves) as the msys API is
+used in exactly the same manner as the mbuf API. The only difference is
+that mbuf pools are added to msys by calling ``os_msys_register().``
+
+
 Using mbufs
 --------------
 
 The following examples illustrate typical mbuf usage. There are two
-basic mbuf allocation API: ``os_mbuf_get()`` and
-``os_mbuf_get_pkthdr()``. The first API obtains a normal mbuf whereas
+basic mbuf allocation API: c:func:`os_mbuf_get()` and
+:c:func:`os_mbuf_get_pkthdr()`. The first API obtains a normal mbuf whereas
 the latter obtains a packet header mbuf. Typically, application
-developers use ``os_mbuf_get_pkthdr()`` and rarely, if ever, need to
-call ``os_mbuf_get()`` as the rest of the mbuf API (e.g.
-``os_mbuf_append()``, ``os_mbuf_copyinto()``, etc.) typically deal with
-allocating and chaining mbufs. It is recommended to use the provided API
-to copy data into/out of mbuf chains and/or manipulate mbufs.
+developers use :c:func:`os_mbuf_get_pkthdr()` and rarely, if ever, need to
+call :c:func:`os_mbuf_get()` as the rest of the mbuf API (e.g.
+:c:func:`os_mbuf_append()`, :c:func:`os_mbuf_copyinto()`, etc.) typically 
+deal with allocating and chaining mbufs. It is recommended to use the 
+provided API to copy data into/out of mbuf chains and/or manipulate mbufs.
 
 In ``example1``, the developer creates a packet and then sends the
 packet to a networking interface. The code sample also provides an
@@ -293,180 +329,91 @@ definitions used in the first example.
         os_mbuf_free_chain(om);
     }
 
-Data Structures
------------------
 
-.. code:: c
+Mqueue
+-------
 
-    struct os_mbuf_pool {
-        uint16_t omp_databuf_len;
-        uint16_t omp_mbuf_count;
-        struct os_mempool *omp_pool;
-        STAILQ_ENTRY(os_mbuf_pool) omp_next;
-    };
-
-+--------------+----------------+
-| **Element**  | **Description* |
-|              | *              |
-+==============+================+
-| omp\_databuf | The length, in |
-| \_len        | bytes, of the  |
-|              | "data buffer"  |
-|              | of the mbuf.   |
-|              | The data       |
-|              | buffer of the  |
-|              | mbuf is        |
-|              | everything     |
-|              | except the     |
-|              | os\_mbuf       |
-|              | structure      |
-|              | (which is      |
-|              | present in all |
-|              | types of       |
-|              | mbufs)         |
-+--------------+----------------+
-| omp\_mbuf\_c | Total number   |
-| ount         | of mbufs in    |
-|              | the pool when  |
-|              | allocated.     |
-|              | This is NOT    |
-|              | the number of  |
-|              | free mbufs in  |
-|              | the pool!      |
-+--------------+----------------+
-| omp\_pool    | The memory     |
-|              | pool from      |
-|              | which the      |
-|              | mbufs are      |
-|              | allocated      |
-+--------------+----------------+
-| omp\_next    | This is a      |
-|              | linked list    |
-|              | pointer which  |
-|              | chains memory  |
-|              | pools. It is   |
-|              | used by the    |
-|              | system memory  |
-|              | pool library   |
-+--------------+----------------+
+The mqueue construct allows a task to wake up when it receives data.
+Typically, this data is in the form of packets received over a network.
+A common networking stack operation is to put a packet on a queue and
+post an event to the task monitoring that queue. When the task handles
+the event, it processes each packet on the packet queue.
 
-.. code:: c
+Using Mqueue
+--------------
+
+The following code sample demonstrates how to use an mqueue. In this
+example:
 
-    struct os_mbuf_pkthdr {
-        uint16_t omp_len;
-        uint16_t omp_flags;
-        STAILQ_ENTRY(os_mbuf_pkthdr) omp_next;
-    };
-
-+--------------+----------------+
-| **Element**  | **Description* |
-|              | *              |
-+==============+================+
-| omp\_len     | Length, in     |
-|              | bytes, of the  |
-|              | "packet". This |
-|              | is the sum of  |
-|              | the user data  |
-|              | in all the     |
-|              | mbufs chained  |
-|              | to the packet  |
-|              | header mbuf    |
-|              | (including the |
-|              | packet header  |
-|              | mbuf)          |
-+--------------+----------------+
-| omp\_flags   | Packet header  |
-|              | flags.         |
-+--------------+----------------+
-| omp\_next    | Linked list    |
-|              | pointer to     |
-|              | chain          |
-|              | "packets".     |
-|              | This can be    |
-|              | used to add    |
-|              | mbuf chains to |
-|              | a queue or     |
-|              | linked list    |
-|              | and is there   |
-|              | for            |
-|              | convenience.   |
-+--------------+----------------+
+-  packets are put on a receive queue
+-  a task processes each packet on the queue (increments a receive
+   counter)
+
+Not shown in the code example is a call ``my_task_rx_data_func``.
+Presumably, some other code will call this API.
 
 .. code:: c
 
-    struct os_mbuf {
-        uint8_t *om_data;
-        uint8_t om_flags;
-        uint8_t om_pkthdr_len;
-        uint16_t om_len;
-        struct os_mbuf_pool *om_omp;
-        SLIST_ENTRY(os_mbuf) om_next;
-        uint8_t om_databuf[0];
-    };
-
-+--------------+----------------+
-| **Element**  | **Description* |
-|              | *              |
-+==============+================+
-| om\_data     | Pointer to     |
-|              | start of user  |
-|              | data in mbuf   |
-|              | data buffer    |
-+--------------+----------------+
-| om\_flags    | mbuf flags     |
-|              | field.         |
-|              | Currently all  |
-|              | flags unused.  |
-+--------------+----------------+
-| om\_pkthdr\_ | The total      |
-| len          | length of all  |
-|              | packet headers |
-|              | in the mbuf    |
-|              | (mbuf packet   |
-|              | header plus    |
-|              | user packet    |
-|              | header), in    |
-|              | bytes          |
-+--------------+----------------+
-| om\_len      | The length of  |
-|              | the user data  |
-|              | contained in   |
-|              | this mbuf, in  |
-|              | bytes          |
-+--------------+----------------+
-| om\_omp      | Memory pool    |
-|              | pointer. This  |
-|              | is the mbuf    |
-|              | pool from      |
-|              | which this     |
-|              | mbuf was       |
-|              | allocated.     |
-+--------------+----------------+
-| om\_next     | Pointer to     |
-|              | next mbuf in   |
-|              | packet chain   |
-+--------------+----------------+
-| om\_databuf  | mbuf data      |
-|              | buffer         |
-|              | (accessor to   |
-|              | start of mbuf  |
-|              | data buffer).  |
-|              | Note that the  |
-|              | mbuf data      |
-|              | buffer refers  |
-|              | to the start   |
-|              | of either the  |
-|              | user data in   |
-|              | normal mbufs   |
-|              | or the start   |
-|              | of the os mbuf |
-|              | packet header  |
-|              | for packet     |
-|              | header mbufs   |
-+--------------+----------------+
+    uint32_t pkts_rxd;
+    struct os_mqueue rxpkt_q;
+    struct os_eventq my_task_evq;
+
+    /**
+     * Removes each packet from the receive queue and processes it.
+     */
+    void
+    process_rx_data_queue(void)
+    {
+        struct os_mbuf *om;
+
+        while ((om = os_mqueue_get(&rxpkt_q)) != NULL) {
+            ++pkts_rxd;
+            os_mbuf_free_chain(om);
+        }
+    }
+
+    /**
+     * Called when a packet is received.
+     */
+    int
+    my_task_rx_data_func(struct os_mbuf *om)
+    {
+        int rc;
+
+        /* Enqueue the received packet and wake up the listening task. */
+        rc = os_mqueue_put(&rxpkt_q, &my_task_evq, om);
+        if (rc != 0) {
+            return -1;
+        }
+
+        return 0;
+    }
+
+    void
+    my_task_handler(void *arg)
+    {
+        struct os_event *ev;
+        struct os_callout_func *cf;
+        int rc;
+
+        /* Initialize eventq */
+        os_eventq_init(&my_task_evq);
+
+        /* Initialize mqueue */
+        os_mqueue_init(&rxpkt_q, NULL);
+
+        /* Process each event posted to our eventq.  When there are no events to
+         * process, sleep until one arrives.
+         */
+        while (1) {
+            os_eventq_run(&my_task_evq);
+        }
+    }
+
 
 API
 -----------------
 
 .. doxygengroup:: OSMbuf
     :content-only:
+    :members:
diff --git a/develop/_sources/os/core_os/memory_pool/memory_pool.rst.txt b/develop/_sources/os/core_os/memory_pool/memory_pool.rst.txt
index 43f20b183..8fbc14940 100644
--- a/develop/_sources/os/core_os/memory_pool/memory_pool.rst.txt
+++ b/develop/_sources/os/core_os/memory_pool/memory_pool.rst.txt
@@ -26,7 +26,7 @@ variable) or dynamically allocated (i.e. from the heap). When
 determining the amount of memory required for the memory pool, simply
 multiplying the number of blocks by the size of each block is not
 sufficient as the OS may have alignment requirements. The alignment size
-definition is named ``OS_ALIGNMENT`` and can be found in os\_arch.h as
+definition is named :c:macro:`OS_ALIGNMENT` and can be found in os\_arch.h as
 it is architecture specific. The memory block alignment is usually for
 efficiency but may be due to other reasons. Generally, blocks are
 aligned on 32-bit boundaries. Note that memory blocks must also be of
@@ -34,16 +34,16 @@ sufficient size to hold a list pointer as this is needed to chain memory
 blocks on the free list.
 
 In order to simplify this for the user two macros have been provided:
-``OS_MEMPOOL_BYTES(n, blksize)`` and ``OS_MEMPOOL_SIZE(n, blksize)``.
+c:macro:`OS_MEMPOOL_BYTES(n, blksize)` and :c:macro:`OS_MEMPOOL_SIZE(n, blksize)`.
 The first macro returns the number of bytes needed for the memory pool
-while the second returns the number of ``os_membuf_t`` elements required
-by the memory pool. The ``os_membuf_t`` type is used to guarantee that
+while the second returns the number of :c:type:`os_membuf_t`` elements required
+by the memory pool. The :c:type:`os_membuf_t` type is used to guarantee that
 the memory buffer used by the memory pool is aligned on the correct
 boundary.
 
 Here are some examples. Note that if a custom malloc implementation is
 used it must guarantee that the memory buffer used by the pool is
-allocated on the correct boundary (i.e. OS\_ALIGNMENT).
+allocated on the correct boundary (i.e. :c:macro:`OS_ALIGNMENT`).
 
 .. code:: c
 
@@ -56,7 +56,7 @@ allocated on the correct boundary (i.e. OS\_ALIGNMENT).
 
 Now that the memory pool has been defined as well as the memory
 required for the memory blocks which make up the pool the user needs to
-initialize the memory pool by calling ``os_mempool_init``.
+initialize the memory pool by calling :c:func:`os_mempool_init``.
 
 .. code:: c
 
@@ -64,94 +64,15 @@ initialize the memory pool by calling ``os_mempool_init``.
                              "MyPool");
 
 Once the memory pool has been initialized the developer can allocate
-memory blocks from the pool by calling ``os_memblock_get``. When the
+memory blocks from the pool by calling :c:func:`os_memblock_get`. When the
 memory block is no longer needed the memory can be freed by calling
-``os_memblock_put``.
-
-Data structures
-----------------
-
-.. code:: c
-
-    struct os_mempool {
-        int mp_block_size;
-        int mp_num_blocks;
-        int mp_num_free;
-        int mp_min_free;
-        uint32_t mp_membuf_addr;
-        STAILQ_ENTRY(os_mempool) mp_list;    
-        SLIST_HEAD(,os_memblock);
-        char *name;
-    };
-
-    struct os_mempool_info {
-        int omi_block_size;
-        int omi_num_blocks;
-        int omi_num_free;
-        int omi_min_free;
-        char omi_name[OS_MEMPOOL_INFO_NAME_LEN];
-    };
-
-+--------------+----------------+
-| **Element**  | **Description* |
-|              | *              |
-+==============+================+
-| mp\_block\_s | Size of the    |
-| ize          | memory blocks, |
-|              | in bytes. This |
-|              | is not the     |
-|              | actual number  |
-|              | of bytes used  |
-|              | by each block; |
-|              | it is the      |
-|              | requested size |
-|              | of each block. |
-|              | The actual     |
-|              | memory block   |
-|              | size will be   |
-|              | aligned to     |
-|              | OS\_ALIGNMENT  |
-|              | bytes          |
-+--------------+----------------+
-| mp\_num\_blo | Number of      |
-| cks          | memory blocks  |
-|              | in the pool    |
-+--------------+----------------+
-| mp\_num\_fre | Number of free |
-| e            | blocks left    |
-+--------------+----------------+
-| mp\_min\_fre | Lowest number  |
-| e            | of free blocks |
-|              | seen           |
-+--------------+----------------+
-| mp\_membuf\_ | The address of |
-| addr         | the memory     |
-|              | block. This is |
-|              | used to check  |
-|              | that a valid   |
-|              | memory block   |
-|              | is being       |
-|              | freed.         |
-+--------------+----------------+
-| mp\_list     | List pointer   |
-|              | to chain       |
-|              | memory pools   |
-|              | so they can be |
-|              | displayed by   |
-|              | newt tools     |
-+--------------+----------------+
-| SLIST\_HEAD( | List pointer   |
-| ,os\_membloc | to chain free  |
-| k)           | memory blocks  |
-+--------------+----------------+
-| name         | Name for the   |
-|              | memory block   |
-+--------------+----------------+
+:c:func:`os_memblock_put`.
 
 API
 -----
 
 .. doxygengroup:: OSMempool
     :content-only:
+    :members:
 
 
diff --git a/develop/_sources/os/core_os/mqueue/mqueue.rst.txt b/develop/_sources/os/core_os/mqueue/mqueue.rst.txt
deleted file mode 100644
index b7c13b858..000000000
--- a/develop/_sources/os/core_os/mqueue/mqueue.rst.txt
+++ /dev/null
@@ -1,95 +0,0 @@
-Mqueue
-======
-
-The mqueue construct allows a task to wake up when it receives data.
-Typically, this data is in the form of packets received over a network.
-A common networking stack operation is to put a packet on a queue and
-post an event to the task monitoring that queue. When the task handles
-the event, it processes each packet on the packet queue.
-
-Using Mqueue
---------------
-
-The following code sample demonstrates how to use an mqueue. In this
-example:
-
--  packets are put on a receive queue
--  a task processes each packet on the queue (increments a receive
-   counter)
-
-Not shown in the code example is a call ``my_task_rx_data_func``.
-Presumably, some other code will call this API.
-
-.. code:: c
-
-    uint32_t pkts_rxd;
-    struct os_mqueue rxpkt_q;
-    struct os_eventq my_task_evq;
-
-    /**
-     * Removes each packet from the receive queue and processes it.
-     */
-    void
-    process_rx_data_queue(void)
-    {
-        struct os_mbuf *om;
-
-        while ((om = os_mqueue_get(&rxpkt_q)) != NULL) {
-            ++pkts_rxd;
-            os_mbuf_free_chain(om);
-        }
-    }
-
-    /**
-     * Called when a packet is received.
-     */
-    int
-    my_task_rx_data_func(struct os_mbuf *om)
-    {
-        int rc;
-
-        /* Enqueue the received packet and wake up the listening task. */
-        rc = os_mqueue_put(&rxpkt_q, &my_task_evq, om);
-        if (rc != 0) {
-            return -1;
-        }
-
-        return 0;
-    }
-
-    void
-    my_task_handler(void *arg)
-    {
-        struct os_event *ev;
-        struct os_callout_func *cf;
-        int rc;
-
-        /* Initialize eventq */
-        os_eventq_init(&my_task_evq);
-
-        /* Initialize mqueue */
-        os_mqueue_init(&rxpkt_q, NULL);
-
-        /* Process each event posted to our eventq.  When there are no events to
-         * process, sleep until one arrives.
-         */
-        while (1) {
-            os_eventq_run(&my_task_evq);
-        }
-    }
-
-Data Structures
-----------------
-
-.. code:: c
-
-    struct os_mqueue {
-        STAILQ_HEAD(, os_mbuf_pkthdr) mq_head;
-        struct os_event mq_ev;
-    };
-
-API
------------------
-
-.. doxygengroup:: OSMqueue
-    :content-only:
diff --git a/develop/_sources/os/core_os/msys/msys.rst.txt b/develop/_sources/os/core_os/msys/msys.rst.txt
deleted file mode 100644
index 8f8420b39..000000000
--- a/develop/_sources/os/core_os/msys/msys.rst.txt
+++ /dev/null
@@ -1,40 +0,0 @@
-Msys
-====
-
-Msys stands for "system mbufs" and is a set of API built on top of the
-mbuf code. The basic idea behind msys is the following. The developer
-can create different size mbuf pools and register them with msys. The
-application then allocates mbufs using the msys API (as opposed to the
-mbuf API). The msys code will choose the mbuf pool with the smallest
-mbufs that can accommodate the requested size.
-
-Let us walk through an example where the user registers three mbuf pools
-with msys: one with 32 byte mbufs, one with 256 and one with 2048. If
-the user requests an mbuf with 10 bytes, the 32-byte mbuf pool is used.
-If the request is for 33 bytes the 256 byte mbuf pool is used. If an
-mbuf data size is requested that is larger than any of the pools (say,
-4000 bytes) the largest pool is used. While this behaviour may not be
-optimal in all cases that is the currently implemented behaviour. All
-this means is that the user is not guaranteed that a single mbuf can
-hold the requested data.
-
-The msys code will not allocate an mbuf from a larger pool if the chosen
-mbuf pool is empty. Similarly, the msys code will not chain together a
-number of smaller mbufs to accommodate the requested size. While this
-behaviour may change in future implementations the current code will
-simply return NULL. Using the above example, say the user requests 250
-bytes. The msys code chooses the appropriate pool (i.e. the 256 byte
-mbuf pool) and attempts to allocate an mbuf from that pool. If that pool
-is empty, NULL is returned even though the 32 and 2048 byte pools are
-not empty.
-
-Note that no added descriptions on how to use the msys API are presented
-here (other than in the API descriptions themselves) as the msys API is
-used in exactly the same manner as the mbuf API. The only difference is
-that mbuf pools are added to msys by calling ``os_msys_register().``
-
-API
------------------
-
-.. doxygengroup:: OSMsys
-    :content-only:
diff --git a/develop/_sources/os/core_os/mutex/mutex.rst.txt b/develop/_sources/os/core_os/mutex/mutex.rst.txt
index 4d56acd46..b4f9d05f3 100644
--- a/develop/_sources/os/core_os/mutex/mutex.rst.txt
+++ b/develop/_sources/os/core_os/mutex/mutex.rst.txt
@@ -18,15 +18,15 @@ tasks start running in order to avoid a task possibly using the mutex
 before it is initialized.
 
 When a task wants exclusive access to a shared resource it needs to
-obtain the mutex by calling *os\_mutex\_pend*. If the mutex is currently
+obtain the mutex by calling :c:func:`os_mutex_pend`. If the mutex is currently
 owned by a different task (a lower priority task), the requesting task
 will be put to sleep and the owners priority will be elevated to the
 priority of the requesting task. Note that multiple tasks can request
 ownership and the current owner is elevated to the highest priority of
 any task waitin on the mutex. When the task is done using the shared
-resource, it needs to release the mutex by called *os\_mutex\_release*.
+resource, it needs to release the mutex by called :c:func:`os_mutex_release`.
 There needs to be one release per call to pend. Note that nested calls
-to *os\_mutex\_pend* are allowed but there needs to be one release per
+to :c:func:`os_mutex_pend` are allowed but there needs to be one release per
 pend.
 
 The following example will illustrate how priority inheritance works. In
@@ -46,52 +46,9 @@ Note that when multiple tasks are waiting on a mutex owned by another
 task, once the mutex is released the highest priority task waiting on
 the mutex is run.
 
-Data structures
-----------------
-
-.. code:: c
-
-    struct os_mutex
-    {
-        SLIST_HEAD(, os_task) mu_head;
-        uint8_t     _pad;
-        uint8_t     mu_prio;
-        uint16_t    mu_level;
-        struct os_task *mu_owner;
-    };
-
-+--------------+----------------+
-| Element      | Description    |
-+==============+================+
-| mu\_head     | Queue head for |
-|              | list of tasks  |
-|              | waiting on     |
-|              | mutex          |
-+--------------+----------------+
-| \_pad        | Padding        |
-+--------------+----------------+
-| mu\_prio     | Default        |
-|              | priority of    |
-|              | owner of       |
-|              | mutex. Used to |
-|              | reset priority |
-|              | of task when   |
-|              | mutex released |
-+--------------+----------------+
-| mu\_level    | Call nesting   |
-|              | level (for     |
-|              | nested calls)  |
-+--------------+----------------+
-| mu\_owner    | Pointer to     |
-|              | task structure |
-|              | which owns     |
-|              | mutex          |
-+--------------+----------------+
-
 API
 ----
 
 .. doxygengroup:: OSMutex
     :content-only:
-
-
+    :members:
diff --git a/develop/_sources/os/core_os/mynewt_os.rst.txt b/develop/_sources/os/core_os/mynewt_os.rst.txt
index 328986dcb..93387239e 100644
--- a/develop/_sources/os/core_os/mynewt_os.rst.txt
+++ b/develop/_sources/os/core_os/mynewt_os.rst.txt
@@ -1,24 +1,21 @@
-Mynewt Core OS
-==============
+Apache Mynewt Operating System Kernel
+======================================
 
 .. toctree::
    :hidden:
 
    context_switch/context_switch
-   cputime/os_cputime
-   time/os_time
    task/task
-   event_queue/event_queue
-   semaphore/semaphore
    mutex/mutex
-   memory_pool/memory_pool
+   semaphore/semaphore
+   event_queue/event_queue
+   callout/callout
    heap/heap
+   memory_pool/memory_pool
    mbuf/mbuf
-   msys/msys
-   mqueue/mqueue
+   cputime/os_cputime
+   time/os_time
    sanity/sanity
-   callout/callout
-   API <API>
 
 The Mynewt Core OS is a multitasking, preemptive real-time operating
 system combining a scheduler with typical RTOS features such as mutexes,
@@ -123,7 +120,7 @@ initialization" function, and dispatches events from the default event
 queue. The application task initialization function is responsible for
 initializing all the data objects that each task exposes to the other
 tasks. The tasks themselves are also initialized at this time (by
-calling ``os_task_init()``).
+calling :c:func:`os_task_init()`).
 
 In the example, each task works in a ping-pong like fashion: task 1
 wakes up, adds a token to semaphore 1 and then waits for a token from
@@ -131,8 +128,8 @@ semaphore 2. Task 2 waits for a token on semaphore 1 and once it gets
 it, adds a token to semaphore 2. Notice that the semaphores are
 initialized by the application specific task initialization functions
 and not inside the task handler functions. If task 2 (being lower in
-priority than task 1) had called os_sem_init() for task2_sem inside
-task2_handler(), task 1 would have called os_sem_pend() using
+priority than task 1) had called :c:func:`os_sem_init()` for task2_sem inside
+task2_handler(), task 1 would have called :c:func:`os_sem_pend()` using
 task2_sem before task2_sem was initialized.
 
 .. code:: c
diff --git a/develop/_sources/os/core_os/os_init.rst.txt b/develop/_sources/os/core_os/os_init.rst.txt
deleted file mode 100644
index 628e3f871..000000000
--- a/develop/_sources/os/core_os/os_init.rst.txt
+++ /dev/null
@@ -1,28 +0,0 @@
-os\_init
---------
-
-.. code-block:: console
-
-    void os_init(void)
-
-Initializes the OS. Must be called before the OS is started (i.e.
-os\_start() is called).
-
-Arguments
-^^^^^^^^^
-
-None
-
-Returned values
-^^^^^^^^^^^^^^^
-
-None
-
-Notes
-^^^^^
-
-The call to os\_init performs architecture and bsp initializations and
-initializes the idle task.
-
-This function does not start the OS, the OS time tick interrupt, or the
-scheduler.
diff --git a/develop/_sources/os/core_os/os_start.rst.txt b/develop/_sources/os/core_os/os_start.rst.txt
deleted file mode 100644
index fd2fa2691..000000000
--- a/develop/_sources/os/core_os/os_start.rst.txt
+++ /dev/null
@@ -1,27 +0,0 @@
-os\_start
----------
-
-.. code-block:: console
-
-    void os_start(void)
-
-Starts the OS by initializing and enabling the OS time tick and starting
-the scheduler.
-
-This function does not return.
-
-Arguments
-^^^^^^^^^
-
-None
-
-Returned values
-^^^^^^^^^^^^^^^
-
-None (does not return).
-
-Notes
-^^^^^
-
-Once os\_start has been called, context is switched to the highest
-priority task that was initialized prior to calling os\_start.
diff --git a/develop/_sources/os/core_os/os_started.rst.txt b/develop/_sources/os/core_os/os_started.rst.txt
deleted file mode 100644
index 486a3d86e..000000000
--- a/develop/_sources/os/core_os/os_started.rst.txt
+++ /dev/null
@@ -1,19 +0,0 @@
-os\_started
------------
-
-.. code-block:: console
-
-    int os_started(void)
-
-Returns 'true' (1) if the os has been started; 0 otherwise.
-
-Arguments
-^^^^^^^^^
-
-None
-
-Returned values
-^^^^^^^^^^^^^^^
-
-Integer value with 0 meaning the OS has not been started and 1
-indicating the OS has been started (i.e. os\_start() has been called).
diff --git a/develop/_sources/os/core_os/sanity/sanity.rst.txt b/develop/_sources/os/core_os/sanity/sanity.rst.txt
index 8e4216935..5211c58a9 100644
--- a/develop/_sources/os/core_os/sanity/sanity.rst.txt
+++ b/develop/_sources/os/core_os/sanity/sanity.rst.txt
@@ -32,13 +32,13 @@ Description
 Sanity Task
 -----------
 
-Mynewt OS uses the OS Idle task to check sanity. The ``SANITY_INTERVAL``
+Mynewt OS uses the OS Idle task to check sanity. The :c:macro:`SANITY_INTERVAL`
 syscfg setting specifies the interval in seconds to perform the sanity
 checks.
 
 By default, every operating system task provides the frequency it will
 check in with the sanity task, with the ``sanity_itvl`` parameter in the
-``os_task_init()`` function:
+c:func:`os_task_init()` function:
 
 .. code:: c
 
@@ -46,7 +46,7 @@ check in with the sanity task, with the ``sanity_itvl`` parameter in the
         void *arg, uint8_t prio, os_time_t sanity_itvl, os_stack_t *bottom,
         uint16_t stack_size);
 
-``sanity_itvl`` is the time in OS time ticks that the task being created
+c:var:`sanity_itvl` is the time in OS time ticks that the task being created
 must register in with the sanity task.
 
 Checking in with Sanity Task
@@ -54,7 +54,7 @@ Checking in with Sanity Task
 
 The task must then register in with the sanity task every
 ``sanity_itvl`` seconds. In order to do that, the task should call the
-``os_sanity_task_checkin`` function, which will reset the sanity check
+:c:func:`os_sanity_task_checkin` function, which will reset the sanity check
 associated with this task. Here is an example of a task that uses a
 callout to checkin with the sanity task every 50 seconds:
 
@@ -105,8 +105,8 @@ Registering a Custom Sanity Check
 
 If a particular task wants to further hook into the sanity framework to
 perform other checks during the sanity task's operation, it can do so by
-registering a ``struct os_sanity_check`` using the
-``os_sanity_check_register`` function.
+registering a :c:type:`struct os_sanity_check` using the
+:c:func:`os_sanity_check_register()` function.
 
 .. code:: c
 
@@ -149,8 +149,8 @@ registering a ``struct os_sanity_check`` using the
 
 In the above example, every time the custom sanity check
 ``mymodule_perform_sanity_check`` returns successfully (0), the sanity
-check is reset. In the ``OS_SANITY_CHECK_SETFUNC`` macro, the sanity
-checkin interval is specified as 50 \* SANITY\_TASK\_INTERVAL (which is
+check is reset. In the c:macro:`OS_SANITY_CHECK_SETFUNC` macro, the sanity
+checkin interval is specified as 50 \* :c:macro:`SANITY_TASK_INTERVAL` (which is
 the interval at which the sanity task runs.) This means that the
 ``mymodule_perform_sanity_check()`` function needs to fail 50 times
 consecutively before the sanity task will crash the system.
@@ -160,73 +160,9 @@ temporarily be exhausted, it's a good idea to have the sanity check fail
 multiple consecutive times before crashing the system. This will avoid
 crashing for temporary failures.
 
-Data structures
----------------
-
-OS Sanity Check
-----------------
-
-.. code:: c
-
-    struct os_sanity_check {
-        os_time_t sc_checkin_last;
-        os_time_t sc_checkin_itvl;
-        os_sanity_check_func_t sc_func;
-        void *sc_arg; 
-
-        SLIST_ENTRY(os_sanity_check) sc_next;
-    };
-
-+--------------+----------------+
-| **Element**  | **Description* |
-|              | *              |
-+==============+================+
-| ``sc_checkin | The last time  |
-| _last``      | this sanity    |
-|              | check checked  |
-|              | in with the    |
-|              | sanity task,   |
-|              | in OS time     |
-|              | ticks.         |
-+--------------+----------------+
-| ``sc_checkin | How frequently |
-| _itvl``      | the sanity     |
-|              | check is       |
-|              | supposed to    |
-|              | check in with  |
-|              | the sanity     |
-|              | task, in OS    |
-|              | time ticks.    |
-+--------------+----------------+
-| ``sc_func``  | If not         |
-|              | ``NULL``, call |
-|              | this function  |
-|              | when running   |
-|              | the sanity     |
-|              | task. If the   |
-|              | function       |
-|              | returns 0,     |
-|              | reset the      |
-|              | sanity check.  |
-+--------------+----------------+
-| ``sc_arg``   | Argument to    |
-|              | pass to        |
-|              | ``sc_func``    |
-|              | when calling   |
-|              | it.            |
-+--------------+----------------+
-| ``sc_next``  | Sanity checks  |
-|              | are chained in |
-|              | the sanity     |
-|              | task when      |
-|              | ``os_sanity_ch |
-|              | eck_register() |
-|              | ``             |
-|              | is called.     |
-+--------------+----------------+
-
 API
 -----------------
 
 .. doxygengroup:: OSSanity
     :content-only:
+    :members:
diff --git a/develop/_sources/os/core_os/semaphore/semaphore.rst.txt b/develop/_sources/os/core_os/semaphore/semaphore.rst.txt
index 8c8b4a24d..04fbff62b 100644
--- a/develop/_sources/os/core_os/semaphore/semaphore.rst.txt
+++ b/develop/_sources/os/core_os/semaphore/semaphore.rst.txt
@@ -19,9 +19,9 @@ semaphore, the initial number of tokens can be set as well.
 
 When used for exclusive access to a shared resource the semaphore only
 needs a single token. In this case, a single task "creates" the
-semaphore by calling *os\_sem\_init* with a value of one (1) for the
+semaphore by calling :c:func:`os_sem_init()` with a value of one (1) for the
 token. When a task desires exclusive access to the shared resource it
-requests the semaphore by calling *os\_sem\_pend*. If there is a token
+requests the semaphore by calling :c:func:`os_sem_pend()`. If there is a token
 the requesting task will acquire the semaphore and continue operation.
 If no tokens are available the task will be put to sleep until there is
 a token. A common "problem" with using a semaphore for exclusive access
@@ -45,48 +45,27 @@ of this would be the following. A task creates a semaphore and
 initializes it with no tokens. The task then waits on the semaphore, and
 since there are no tokens, the task is put to sleep. When other tasks
 want to wake up the sleeping task they simply add a token by calling
-*os\_sem\_release*. This will cause the sleeping task to wake up
+:c:func:`os_sem_release()`. This will cause the sleeping task to wake up
 (instantly if no other higher priority tasks want to run).
 
 The other common use of a counting semaphore is in what is commonly
 called a "producer/consumer" relationship. The producer adds tokens (by
-calling *os\_sem\_release*) and the consumer consumes them by calling
-*os\_sem\_pend*. In this relationship, the producer has work for the
+calling :c:func:`os_sem_release()`) and the consumer consumes them by calling
+:c:func:`os_sem_pend()`. In this relationship, the producer has work for the
 consumer to do. Each token added to the semaphore will cause the
 consumer to do whatever work is required. A simple example could be the
 following: every time a button is pressed there is some work to do (ring
 a bell). Each button press causes the producer to add a token. Each
 token consumed rings the bell. There will exactly the same number of
 bell rings as there are button presses. In other words, each call to
-*os\_sem\_pend* subtracts exactly one token and each call to
-*os\_sem\_release* adds exactly one token.
-
-Data structures
-----------------
-
-.. code:: c
-
-    struct os_sem
-    {
-        SLIST_HEAD(, os_task) sem_head;     /* chain of waiting tasks */
-        uint16_t    _pad;
-        uint16_t    sem_tokens;             /* # of tokens */
-    };
-
-+---------------+-----------------------------------------------------+
-| Element       | Description                                         |
-+===============+=====================================================+
-| sem\_head     | Queue head for list of tasks waiting on semaphore   |
-+---------------+-----------------------------------------------------+
-| \_pad         | Padding for alignment                               |
-+---------------+-----------------------------------------------------+
-| sem\_tokens   | Current number of tokens                            |
-+---------------+-----------------------------------------------------+
+:c:func:`os_sem_pend()` subtracts exactly one token and each call to
+:c:func:`os_sem_release()` adds exactly one token.
 
 API
 ----
 
 .. doxygengroup:: OSSem
     :content-only:
+    :members:
 
 
diff --git a/develop/_sources/os/core_os/task/task.rst.txt b/develop/_sources/os/core_os/task/task.rst.txt
index 2a3498444..01cf85a06 100644
--- a/develop/_sources/os/core_os/task/task.rst.txt
+++ b/develop/_sources/os/core_os/task/task.rst.txt
@@ -37,7 +37,7 @@ stack size can be a bit tricky; generally developers should not declare
 large local variables on the stack so that task stacks can be of limited
 size. However, all applications are different and the developer must
 choose the stack size accordingly. NOTE: be careful when declaring your
-stack! The stack is in units of ``os_stack_t`` sized elements (generally
+stack! The stack is in units of :c:type:`os_stack_t` sized elements (generally
 32-bits). Looking at the example given below and assuming ``os_stack_t``
 is defined to be a 32-bit unsigned value, "my_task_stack" will use 256
 bytes.
@@ -107,3 +107,11 @@ task. This task simply toggles an LED at a one second interval.
         }
         /* main never returns */
     }
+
+
+API
+----
+
+.. doxygengroup:: OSTask
+    :content-only:
+    :members:
diff --git a/develop/_sources/os/core_os/time/os_time.rst.txt b/develop/_sources/os/core_os/time/os_time.rst.txt
index 8a4e24907..831d41c27 100644
--- a/develop/_sources/os/core_os/time/os_time.rst.txt
+++ b/develop/_sources/os/core_os/time/os_time.rst.txt
@@ -68,7 +68,7 @@ Functions
 Function            	          Description
 =============================== ====================
 :c:func:`os_time_advance()`	    Increments the OS time tick for the system.
-:c:func:`os_time_delay()`	      Put the current task to sleep for the given number of ticks.
+:c:func:`os_time_delay()`	    Put the current task to sleep for the given number of ticks.
 :c:func:`os_time_get()`	        Get the current value of OS time.
 :c:func:`os_time_ms_to_ticks()`	Converts milliseconds to os ticks.
 :c:func:`os_get_uptime_usec()`	Gets the time duration since boot.
@@ -117,3 +117,11 @@ the OS time epoch is 49.7 days.
 If two times are more than 1/2 the OS time epoch apart, any time
 comparison will be incorrect. Ensure at design time that comparisons
 will not occur between times that are more than half the OS time epoch.
+
+
+API
+-----
+
+.. doxygengroup:: OSTime
+    :content-only:
+    :members:
diff --git a/develop/_sources/os/modules/hal/hal.rst.txt b/develop/_sources/os/modules/hal/hal.rst.txt
index a1cb41940..201b7d51d 100644
--- a/develop/_sources/os/modules/hal/hal.rst.txt
+++ b/develop/_sources/os/modules/hal/hal.rst.txt
@@ -1,6 +1,19 @@
 Hardware Abstraction Layer
 ==========================
 
+.. toctree::
+    :hidden:
+
+    hal_timer/hal_timer
+    hal_gpio/hal_gpio
+    hal_uart/hal_uart
+    hal_spi/hal_spi
+    hal_i2c/hal_i2c
+    hal_flash/hal_flash
+    hal_system/hal_system
+    hal_watchdog/hal_watchdog
+    hal_bsp/hal_bsp
+
 Description
 ~~~~~~~~~~~
 
diff --git a/develop/_sources/os/modules/hal/hal_api.rst.txt b/develop/_sources/os/modules/hal/hal_api.rst.txt
deleted file mode 100644
index 1214f6e0e..000000000
--- a/develop/_sources/os/modules/hal/hal_api.rst.txt
+++ /dev/null
@@ -1,77 +0,0 @@
-HAL Interfaces
-==============
-
-The HAL supports separate interfaces for many peripherals. A brief
-description of the interfaces are shown below.
-
-+-----------------+-------------------------+---------------------+
-| **Hal Name**    | \*\* Interface File     | **Description **    |
-|                 | \*\*                    |                     |
-+=================+=========================+=====================+
-| `bsp <hal_bsp/h | `hal\_bsp.h <https://gi | An hardware         |
-| al_bsp.html>`__   | thub.com/apache/incubat | independent         |
-|                 | or-mynewt-core/blob/dev | interface to        |
-|                 | elop/hw/hal/include/hal | identify and access |
-|                 | /hal_bsp.h>`__          | underlying BSP.     |
-+-----------------+-------------------------+---------------------+
-| `flash api for  | `hal\_flash.h <https:// | A blocking          |
-| apps to         | github.com/apache/incub | interface to access |
-| use <hal_flash/ | ator-mynewt-core/blob/d | flash memory.       |
-| hal_flash.html>`_ | evelop/hw/hal/include/h |                     |
-| _               | al/hal_flash.h>`__      |                     |
-+-----------------+-------------------------+---------------------+
-| `flash api for  | `flash\_map.h <https:// | An interface to     |
-| drivers to      | github.com/apache/incub | query information   |
-| implement <hal_ | ator-mynewt-core/blob/d | about the flash map |
-| flash/hal_flash | evelop/hw/hal/include/h | (regions and        |
-| _int.html>`__     | al/hal_flash_int.h>`__  | sectors)            |
-+-----------------+-------------------------+---------------------+
-| `gpio <hal_gpio | `hal\_gpio.h <https://g | An interface for    |
-| /hal_gpio.html>`_ | ithub.com/apache/incuba | manipulating        |
-| _               | tor-mynewt-core/blob/de | General Purpose     |
-|                 | velop/hw/hal/include/ha | Inputs and Outputs. |
-|                 | l/hal_gpio.h>`__        |                     |
-+-----------------+-------------------------+---------------------+
-| `i2c <hal_i2c/h | `hal\_i2c.h <https://gi | An interface for    |
-| al_i2c.html>`__   | thub.com/apache/incubat | controlling         |
-|                 | or-mynewt-core/blob/dev | Inter-Integrated-Ci |
-|                 | elop/hw/hal/include/hal | rcuit               |
-|                 | /hal_i2c.h>`__          | (i2c) devices.      |
-+-----------------+-------------------------+---------------------+
-| `OS             | `hal\_os\_tick.h <https | An interface to set |
-| tick <hal_os_ti | ://github.com/apache/in | up interrupt timers |
-| ck/hal_os_tick. | cubator-mynewt-core/blo | or halt CPU in      |
-| md>`__          | b/develop/hw/hal/includ | terms of OS ticks.  |
-|                 | e/hal/hal_os_tick.h>`__ |                     |
-+-----------------+-------------------------+---------------------+
-| `spi <hal_spi/h | `hal\_spi.h <https://gi | An interface for    |
-| al_spi.html>`__   | thub.com/apache/incubat | controlling Serial  |
-|                 | or-mynewt-core/blob/dev | Peripheral          |
-|                 | elop/hw/hal/include/hal | Interface (SPI)     |
-|                 | /hal_spi.h>`__          | devices.            |
-+-----------------+-------------------------+---------------------+
-| `system <hal_sy | `hal\_system.h <https:/ | An interface for    |
-| stem/hal_sys.md | /github.com/apache/incu | starting and        |
-| >`__            | bator-mynewt-core/blob/ | resetting the       |
-|                 | develop/hw/hal/include/ | system.             |
-|                 | hal/hal_system.h>`__    |                     |
-+-----------------+-------------------------+---------------------+
-| `timer <hal_tim | `hal\_cputime.h <https: | An interface for    |
-| er/hal_timer.md | //github.com/apache/inc | configuring and     |
-| >`__            | ubator-mynewt-core/tree | running HW timers   |
-|                 | /develop/hw/hal/include |                     |
-|                 | /hal/hal_timer.h>`__    |                     |
-+-----------------+-------------------------+---------------------+
-| `uart <hal_uart | `hal\_uart.h <https://g | An interface for    |
-| /hal_uart.html>`_ | ithub.com/apache/incuba | communicating via   |
-| _               | tor-mynewt-core/blob/de | asynchronous serial |
-|                 | velop/hw/hal/include/ha | interface.          |
-|                 | l/hal_uart.h>`__        |                     |
-+-----------------+-------------------------+---------------------+
-| `watchdog <hal_ | `hal\_watchdog.h <https | An interface for    |
-| watchdog/hal_wa | ://github.com/apache/in | enabling internal   |
-| tchdog.html>`__   | cubator-mynewt-core/blo | hardware watchdogs. |
-|                 | b/develop/hw/hal/includ |                     |
-|                 | e/hal/hal_watchdog.h>`_ |                     |
-|                 | _                       |                     |
-+-----------------+-------------------------+---------------------+
diff --git a/develop/_sources/os/modules/hal/hal_bsp/hal_bsp.rst.txt b/develop/_sources/os/modules/hal/hal_bsp/hal_bsp.rst.txt
index ae9872bf2..16d573d34 100644
--- a/develop/_sources/os/modules/hal/hal_bsp/hal_bsp.rst.txt
+++ b/develop/_sources/os/modules/hal/hal_bsp/hal_bsp.rst.txt
@@ -1,4 +1,4 @@
-hal\_bsp
+BSP 
 ========
 
 This is the hardware independent BSP (Board Support Package) Interface
@@ -10,12 +10,9 @@ Description
 Contains the basic operations to initialize, specify memory to include
 in coredump, configure interrupt priority etc.
 
-Definition
+API
 ~~~~~~~~~~
 
-`hal\_bsp.h <https://github.com/apache/incubator-mynewt-core/blob/master/hw/hal/include/hal/hal_bsp.h>`__
-
-Examples
-~~~~~~~~
-
---------------
+.. doxygengroup:: HALBsp
+    :content-only:
+    :members:
diff --git a/develop/_sources/os/modules/hal/hal_flash/hal_flash.rst.txt b/develop/_sources/os/modules/hal/hal_flash/hal_flash.rst.txt
index 0ca447472..c9b24c44d 100644
--- a/develop/_sources/os/modules/hal/hal_flash/hal_flash.rst.txt
+++ b/develop/_sources/os/modules/hal/hal_flash/hal_flash.rst.txt
@@ -1,4 +1,4 @@
-hal\_flash
+Flash
 ==========
 
 The hardware independent interface to flash memory that is used by
@@ -10,10 +10,9 @@ Description
 The API offers basic initialization, read, write, erase, sector erase,
 and other operations.
 
-Definition
+API
 ~~~~~~~~~~
 
-`hal\_flash.h <https://github.com/apache/incubator-mynewt-core/blob/master/hw/hal/include/hal/hal_flash.h>`__
-
-Examples
-~~~~~~~~
+.. doxygengroup:: HALFlash
+    :content-only:
+    :members:
diff --git a/develop/_sources/os/modules/hal/hal_gpio/hal_gpio.rst.txt b/develop/_sources/os/modules/hal/hal_gpio/hal_gpio.rst.txt
index b3d000906..22050c2bd 100644
--- a/develop/_sources/os/modules/hal/hal_gpio/hal_gpio.rst.txt
+++ b/develop/_sources/os/modules/hal/hal_gpio/hal_gpio.rst.txt
@@ -1,4 +1,4 @@
-hal\_gpio
+GPIO
 =========
 
 This is the hardware independent GPIO (General Purpose Input Output)
@@ -54,21 +54,11 @@ Said another way, in this specific system we get
 
     SYSTEM_LED --> hal_gpio virtual pin 37 --> port C pin 5 on the stm34F4xx
 
-Definition
+API
 ~~~~~~~~~~
 
-`hal\_gpio.h <https://github.com/apache/incubator-mynewt-core/blob/master/hw/hal/include/hal/hal_gpio.h>`__
+.. doxygengroup:: HALGpio
+    :content-only:
+    :members:
 
-Examples
-~~~~~~~~
 
-Blinky
-^^^^^^
-
-Blinky uses the hal\_gpio to blink the system LED. The blinky source
-code is available in the `blinky
-repo <https://github.com/apache/incubator-mynewt-blinky/blob/master/apps/blinky/src/main.c>`__.
-Examine how ``blinky_task_handler`` initializes and toggles the GPIO to
-control the LED.
-
---------------
diff --git a/develop/_sources/os/modules/hal/hal_i2c/hal_i2c.rst.txt b/develop/_sources/os/modules/hal/hal_i2c/hal_i2c.rst.txt
index 2635195ef..d6c2e1b39 100644
--- a/develop/_sources/os/modules/hal/hal_i2c/hal_i2c.rst.txt
+++ b/develop/_sources/os/modules/hal/hal_i2c/hal_i2c.rst.txt
@@ -1,4 +1,4 @@
-hal\_i2c
+I2C
 ========
 
 The hardware independent interface to I2C Devices.
@@ -16,11 +16,6 @@ I2C is often though of as a 2-wire protocol because it uses two wires
 For a detailed description of I2C, see the `I?C wikipedia
 page <https://en.wikipedia.org/wiki/I?C>`__
 
-Definition
-~~~~~~~~~~
-
-`hal\_i2c.h <https://github.com/apache/incubator-mynewt-core/blob/master/hw/hal/include/hal/hal_i2c.h>`__
-
 HAL\_I2C Theory Of Operation
 ~~~~~~~~~~~~~~~~~~~~~~~~~~~~
 
@@ -94,3 +89,11 @@ In the HAL\_I2C API you would communicate with this device with address
 ``0b1000110``, which is hex 0x46 or decimal 70. The I?C drive would add
 the R/W bit and transmit it as hex 0x8C (binary 10001100) or 0x8D
 (binary 10001101) depending whether it was a read or write command.
+
+
+API
+~~~~~~~~~~
+
+.. doxygengroup:: HALI2c
+    :content-only:
+    :members:
diff --git a/develop/_sources/os/modules/hal/hal_os_tick/hal_os_tick.rst.txt b/develop/_sources/os/modules/hal/hal_os_tick/hal_os_tick.rst.txt
index 343b9b88e..14c8e0c96 100644
--- a/develop/_sources/os/modules/hal/hal_os_tick/hal_os_tick.rst.txt
+++ b/develop/_sources/os/modules/hal/hal_os_tick/hal_os_tick.rst.txt
@@ -1,4 +1,4 @@
-hal\_os\_tick
+OS Tick 
 =============
 
 The hardware independent interface to set up interrupt timers or halt
@@ -24,15 +24,11 @@ You can halt CPU for up to ``n`` ticks:
 The function implementations are in the mcu-specific directories such as
 ``hw/mcu/nordic/nrf51xxx/src/hal_os_tick.c``.
 
-Definition
+API
 ~~~~~~~~~~
 
-`hal\_os\_tick.h <https://github.com/apache/incubator-mynewt-core/blob/master/hw/hal/include/hal/hal_os_tick.h>`__
+.. doxygengroup:: HALOsTick
+    :content-only:
+    :members:
 
-Examples
-~~~~~~~~
 
-An example of the API being used by the OS kernel for the Cortex M0
-architecture to initialize and start the system clock timer can be seen
-in
-`kernel/os/src/arch/cortex\_m0/os\_arch\_arm.c <https://github.com/apache/incubator-mynewt-core/blob/master/kernel/os/src/arch/cortex_m0/os_arch_arm.c>`__.
diff --git a/develop/_sources/os/modules/hal/hal_spi/hal_spi.rst.txt b/develop/_sources/os/modules/hal/hal_spi/hal_spi.rst.txt
index f17bd6b0c..8837134f0 100644
--- a/develop/_sources/os/modules/hal/hal_spi/hal_spi.rst.txt
+++ b/develop/_sources/os/modules/hal/hal_spi/hal_spi.rst.txt
@@ -1,4 +1,4 @@
-hal\_spi
+SPI
 ========
 
 SPI (Serial Peripheral Interface) is a synchronous 4-wire serial
@@ -14,12 +14,8 @@ The Mynewt HAL interface supports the SPI master functionality with both
 blocking and non-blocking interface. SPI slave functionality is
 supported in non-blocking mode.
 
-Definition
-~~~~~~~~~~
-
-`hal\_spi.h <https://github.com/apache/incubator-mynewt-core/blob/master/hw/hal/include/hal/hal_spi.h>`__
 
-HAL\_SPI Theory Of Operation
+Theory Of Operation
 ~~~~~~~~~~~~~~~~~~~~~~~~~~~~
 
 SPI is called a 4-wire interface because of the 4 signals, MISO, MOSI,
@@ -63,3 +59,12 @@ The SPI settings consist of the following:
 The Mynewt SPI HAL does not include built-in SS (Slave Select)
 signaling. It's up to the hal\_spi user to control their own SS pins.
 Typically applications will do this with GPIO.
+
+API
+~~~~~~~~~~
+
+.. doxygengroup:: HALSpi
+    :content-only:
+    :members:
+
+
diff --git a/develop/_sources/os/modules/hal/hal_system/hal_sys.rst.txt b/develop/_sources/os/modules/hal/hal_system/hal_sys.rst.txt
index d0f7d2ad0..d16303bfa 100644
--- a/develop/_sources/os/modules/hal/hal_system/hal_sys.rst.txt
+++ b/develop/_sources/os/modules/hal/hal_system/hal_sys.rst.txt
@@ -1,4 +1,4 @@
-hal\_system
+System
 ===========
 
 A hardware independent interface for starting and resetting the system.
@@ -13,10 +13,10 @@ implemented in the MCU specific directories e.g. ``hal_reset_cause.c``,
 ``/hw/mcu/nordic/nrf52xxx/src/`` directory for Nordic nRF52 series of
 chips.
 
-Definition
+API
 ~~~~~~~~~~
 
-`hal\_system.h <https://github.com/apache/incubator-mynewt-core/blob/master/hw/hal/include/hal/hal_system.h>`__
+.. doxygengroup:: HALSystem
+    :content-only:
+    :members:
 
-Examples
-~~~~~~~~
diff --git a/develop/_sources/os/modules/hal/hal_timer/hal_timer.rst.txt b/develop/_sources/os/modules/hal/hal_timer/hal_timer.rst.txt
index a3b7a0fb9..4fc166785 100644
--- a/develop/_sources/os/modules/hal/hal_timer/hal_timer.rst.txt
+++ b/develop/_sources/os/modules/hal/hal_timer/hal_timer.rst.txt
@@ -1,4 +1,4 @@
-hal\_timer
+Timer
 ==========
 
 The hardware independent timer structure and API to configure,
@@ -27,10 +27,9 @@ structure; the hal timer API should be used.
         TAILQ_ENTRY(hal_timer) link;    /* Queue linked list structure */
     };
 
-Definition
-~~~~~~~~~~
-
-`hal\_timer.h <https://github.com/apache/incubator-mynewt-core/blob/master/hw/hal/include/hal/hal_timer.h>`__
-
-Examples
+API
 ~~~~~~~~
+
+.. doxygengroup:: HALTimer
+    :content-only:
+    :members:
diff --git a/develop/_sources/os/modules/hal/hal_uart/hal_uart.rst.txt b/develop/_sources/os/modules/hal/hal_uart/hal_uart.rst.txt
index 1f490d8a7..3ebcd02c8 100644
--- a/develop/_sources/os/modules/hal/hal_uart/hal_uart.rst.txt
+++ b/develop/_sources/os/modules/hal/hal_uart/hal_uart.rst.txt
@@ -1,4 +1,4 @@
-hal\_uart
+UART
 =========
 
 The hardware independent UART interface for Mynewt.
@@ -11,11 +11,6 @@ Contains the basic operations to send and receive data over a UART
 to apply settings such as speed, parity etc. to the UART. The UART port
 should be closed before any reconfiguring.
 
-Definition
-~~~~~~~~~~
-
-`hal\_uart.h <https://github.com/apache/incubator-mynewt-core/blob/master/hw/hal/include/hal/hal_uart.h>`__
-
 Examples
 ~~~~~~~~
 
@@ -34,3 +29,12 @@ mode where the UART has to block until character has been sent.
         }
         hal_uart_blocking_tx(MY_UART, '\n');
     }
+
+API
+~~~~
+
+.. doxygengroup:: HALUart
+    :content-only:
+    :members:
+
+
diff --git a/develop/_sources/os/modules/hal/hal_watchdog/hal_watchdog.rst.txt b/develop/_sources/os/modules/hal/hal_watchdog/hal_watchdog.rst.txt
index d96359c75..241c90c75 100644
--- a/develop/_sources/os/modules/hal/hal_watchdog/hal_watchdog.rst.txt
+++ b/develop/_sources/os/modules/hal/hal_watchdog/hal_watchdog.rst.txt
@@ -1,4 +1,4 @@
-hal\_watchdog
+Watchdog
 =============
 
 The hardware independent interface to enable internal hardware
@@ -18,15 +18,9 @@ Watchdog needs to be then started with a call to
 ``hal_watchdog_enable()``. Watchdog should be tickled periodically with
 a frequency smaller than 'expire\_secs' using ``hal_watchdog_tickle()``.
 
-Definition
-~~~~~~~~~~
-
-`hal\_watchdog <https://github.com/apache/incubator-mynewt-core/blob/master/hw/hal/include/hal/hal_watchdog.h>`__
-
-Examples
+API
 ~~~~~~~~
 
-The OS initializes and starts a watchdog timer and tickles it
-periodically to check that the OS is running properly. This can be seen
-in
-`/kernel/os/src/os.c <https://github.com/apache/incubator-mynewt-core/blob/master/kernel/os/src/os.c>`__.
+.. doxygengroup:: HALWatchdog
+    :content-only:
+    :members:
diff --git a/develop/_sources/os/os_user_guide.rst.txt b/develop/_sources/os/os_user_guide.rst.txt
index 57556fe51..66e3c9066 100644
--- a/develop/_sources/os/os_user_guide.rst.txt
+++ b/develop/_sources/os/os_user_guide.rst.txt
@@ -4,10 +4,11 @@ OS User Guide
 .. toctree::
    :hidden:
 
-   OS Core <core_os/mynewt_os>
-   core_os/porting/port_os
-   modules/console/console
-   modules/sysinitconfig/sysinitconfig
+   Kernel <core_os/mynewt_os>
+   Hardware Abstraction <modules/hal/hal>
+   Porting Guide <core_os/porting/port_os>
+   System Configuration <modules/sysinitconfig/sysinitconfig>
+   Console <modules/console/console>
 
 This guide provides comprehensive information about Mynewt OS, the
 real-time operating system for embedded systems. It is intended both for
diff --git a/develop/_sources/os/tutorials/codesize.rst.txt b/develop/_sources/os/tutorials/codesize.rst.txt
deleted file mode 100644
index 163c18aba..000000000
--- a/develop/_sources/os/tutorials/codesize.rst.txt
+++ /dev/null
@@ -1,38 +0,0 @@
-How to Reduce Application Code Size
------------------------------------
-
-Gettng your application to fit in an image slot can be challenging,
-particularly on flash constrained hardware such as the nRF51. Below are
-some suggested system configuration settings that reduce the code size
-of your Mynewt image.
-
-+------------------------+---------------------------------------------+
-| Setting                | Description                                 |
-+========================+=============================================+
-| LOG\_LEVEL: 255        | Disable all logging.                        |
-+------------------------+---------------------------------------------+
-| LOG\_CLI: 0            | Disable log shell commands.                 |
-+------------------------+---------------------------------------------+
-| STATS\_CLI: 0          | Disable stats shell commands.               |
-+------------------------+---------------------------------------------+
-| SHELL\_TASK: 0         | Disable the interactive shell.              |
-+------------------------+---------------------------------------------+
-| SHELL\_OS\_MODULE: 0   | Disable memory management shell commands.   |
-+------------------------+---------------------------------------------+
-| SHELL\_CMD\_HELP: 0    | Disable help for shell commands.            |
-+------------------------+---------------------------------------------+
-
-You can use the ``newt target set`` command to set the syscfg settings
-in the ``syscfg.yml`` file for the target. See the `Newt Tool Command
-Guide </newt/command_list/newt_target>`__ for the command syntax.
-
-**Note:** The ``newt target set`` command deletes all the current syscfg
-settings in the target ``syscfg.yml`` file and only sets the syscfg
-settings specified in the command. If you are experimenting with
-different settings to see how they affect the code size and do not want
-to reenter all the setting values in the ``newt target set`` command,
-you can use the ``newt target amend`` command. This command adds or
-updates only the settings specified in the command and does not
-overwrite other setting values. While you can also edit the target
-``syscfg.yml`` file directly, we recommend that you use the
-``newt target`` commands.
diff --git a/develop/_sources/os/tutorials/unit_test.rst.txt b/develop/_sources/os/tutorials/unit_test.rst.txt
deleted file mode 100644
index 21c8e0b8e..000000000
--- a/develop/_sources/os/tutorials/unit_test.rst.txt
+++ /dev/null
@@ -1,359 +0,0 @@
-Write a Test Suite for a Package
-================================
-
-This document guides the reader through creating a test suite for a
-Mynewt package.
-
-Introduction
-------------
-
-Writing a test suite involves using the
-```test/testutil`` <../modules/testutil/testutil.html>`__ package. The
-testutil library provides the functionality needed to define test suites
-and test cases.
-
-Choose Your Package Under Test
-------------------------------
-
-Choose the package you want to write a test suite for. In this tutorial,
-we will use the ``time/datetime`` in the apache-mynewt-core repo.
-Throughout this tutorial, we will be inside the apache-mynewt-core repo
-directory, unlike most tutorials which operate from the top-level
-project directory.
-
-Create A Test Package
----------------------
-
-Typically, a library has only one test package. The convention is name
-the test package by appending ``/test`` to the host library name. For
-example, the test package for ``encoding/json`` is
-``encoding/json/test``. The directory structure of the json package is
-shown below:
-
-.. code:: c
-
-    encoding/json
-    ??? include
-    ??? ??? json
-    ???     ??? json.h
-    ??? pkg.yml
-    ??? src
-    ??? ??? json_decode.c
-    ??? ??? json_encode.c
-    ??? test
-        ??? pkg.yml
-        ??? src
-            ??? test_json.c
-            ??? test_json.h
-            ??? test_json_utils.c
-            ??? testcases
-                ??? json_simple_decode.c
-                ??? json_simple_encode.c
-
-The top-level ``test`` directory contains the json test package. To
-create a test package for the datetime package, we need to create a
-similar package called ``time/datetime/test``.
-
-::
-
-    $ newt pkg new time/datetime/test -t unittest
-    Download package template for package type pkg.
-    Package successfuly installed into /home/me/mynewt-core/time/datetime/test.
-
-We now have a test package inside ``time/datetime``:
-
-::
-
-    time/datetime
-    ??? include
-    ??? ??? datetime
-    ???     ??? datetime.h
-    ??? pkg.yml
-    ??? src
-    ??? ??? datetime.c
-    ??? test
-        ??? README.md
-        ??? pkg.yml
-        ??? src
-        ??? ??? main.c
-        ??? syscfg.yml
-
-There is one modification we need to make to the new package before we
-can start writing unit test code. A test package needs access to the
-code it will be testing, so we need to add a dependency on
-``@apache-mynewt-core/time/datetime`` to our ``pkg.yml`` file:
-
-.. code:: hl_lines="10"
-
-    pkg.name: "time/datetime/test"
-    pkg.type: unittest
-    pkg.description: "Description of your package"
-    pkg.author: "You <yo...@you.org>"
-    pkg.homepage: "http://your-url.org/"
-    pkg.keywords:
-
-    pkg.deps:
-        - '@apache-mynewt-core/test/testutil'
-        - '@apache-mynewt-core/time/datetime'
-
-    pkg.deps.SELFTEST:
-        - '@apache-mynewt-core/sys/console/stub'
-
-While we have the ``pkg.yml`` file open, let's take a look at what newt
-filled in automatically:
-
--  ``pkg.type: unittest`` designates this as a test package. A *test
-   package* is special in that it can be built and executed using the
-   ``newt test`` command.
--  A test package always depends on
-   ``@apache-mynewt-core/test/testutil``. The testutil library provides
-   the tools necessary for verifying package behavior,
--  The ``SELFTEST`` suffix indicates that a setting should only be
-   applied when the ``newt test`` command is used.
-
-Regarding the conditional dependency on ``sys/console/stub``, the
-datetime package requires some form of console to function. In a regular
-application, the console dependency would be supplied by a higher order
-package. Because ``newt test`` runs the test package without an
-application present, the test package needs to supply all unresolved
-dependencies itself when run in self-test mode.
-
-Create Your Test Suite Code
----------------------------
-
-We will be adding a *test suite* to the ``main.c`` file. The test suite
-will be empty for now. We also need to invoke the test suite from
-``main()``.
-
-Our ``main.c`` file now looks like this:
-
-.. code:: c
-
-    #include "sysinit/sysinit.h"
-    #include "testutil/testutil.h"
-
-    TEST_SUITE(test_datetime_suite) {
-        /* Empty for now; add test cases later. */
-    }
-
-    #if MYNEWT_VAL(SELFTEST)
-    int
-    main(int argc, char **argv)
-    {
-        /* Initialize all packages. */
-        sysinit();
-
-        test_datetime_suite();
-
-        /* Indicate whether all test cases passed. */
-        return tu_any_failed;
-    }
-    #endif
-
-Try It Out
-----------
-
-We now have a working test suite with no tests. Let's make sure we get a
-passing result when we run ``newt test``:
-
-::
-
-    $ newt test time/datetime
-    <build output>
-    Executing test: /home/me/mynewt-core/bin/targets/unittest/time_datetime_test/app/time/datetime/test/time_datetime_test.elf
-    Passed tests: [time/datetime/test]
-    All tests passed
-
-Create a Test
--------------
-
-To create a test within your test suite, there are two things to do.
-
-1. Implement the test case function using the ``testutil`` macros.
-2. Call the test case function from within the test suite.
-
-For this tutorial we will create a test case to verify the
-``datetime_parse()`` function. The ``datetime_parse()`` function is
-declared as follows:
-
-.. code:: c
-
-    /**
-     * Parses an RFC 3339 datetime string.  Some examples of valid datetime strings
-     * are:
-     * 2016-03-02T22:44:00                  UTC time (implicit)
-     * 2016-03-02T22:44:00Z                 UTC time (explicit)
-     * 2016-03-02T22:44:00-08:00            PST timezone
-     * 2016-03-02T22:44:00.1                fractional seconds
-     * 2016-03-02T22:44:00.101+05:30        fractional seconds with timezone
-     *
-     * On success, the two output parameters are filled in (tv and tz).
-     *
-     * @return                      0 on success;
-     *                              nonzero on parse error.
-     */
-    int
-    datetime_parse(const char *input, struct os_timeval *tv, struct os_timezone *tz)
-
-Our test case should make sure this function rejects invalid input, and
-that it parses valid input correctly. The updated ``main.c`` file looks
-like this:
-
-.. code:: c
-
-    #include "sysinit/sysinit.h"
-    #include "testutil/testutil.h"
-    #include "os/os_time.h"
-    #include "datetime/datetime.h"
-
-    TEST_SUITE(test_datetime_suite)
-    {
-        test_datetime_parse_simple();
-    }
-
-    TEST_CASE(test_datetime_parse_simple)
-    {
-        struct os_timezone tz;
-        struct os_timeval tv;
-        int rc;
-
-        /*** Valid input. */
-
-        /* No timezone; UTC implied. */
-        rc = datetime_parse("2017-06-28T22:37:59", &tv, &tz);
-        TEST_ASSERT_FATAL(rc == 0);
-        TEST_ASSERT(tv.tv_sec == 1498689479);
-        TEST_ASSERT(tv.tv_usec == 0);
-        TEST_ASSERT(tz.tz_minuteswest == 0);
-        TEST_ASSERT(tz.tz_dsttime == 0);
-
-        /* PDT timezone. */
-        rc = datetime_parse("2013-12-05T02:43:07-07:00", &tv, &tz);
-        TEST_ASSERT_FATAL(rc == 0);
-        TEST_ASSERT(tv.tv_sec == 1386236587);
-        TEST_ASSERT(tv.tv_usec == 0);
-        TEST_ASSERT(tz.tz_minuteswest == 420);
-        TEST_ASSERT(tz.tz_dsttime == 0);
-
-        /*** Invalid input. */
-
-        /* Nonsense. */
-        rc = datetime_parse("abc", &tv, &tz);
-        TEST_ASSERT(rc != 0);
-
-        /* Date-only. */
-        rc = datetime_parse("2017-01-02", &tv, &tz);
-        TEST_ASSERT(rc != 0);
-
-        /* Zero month. */
-        rc = datetime_parse("2017-00-28T22:37:59", &tv, &tz);
-        TEST_ASSERT(rc != 0);
-
-        /* 13 month. */
-        rc = datetime_parse("2017-13-28T22:37:59", &tv, &tz);
-        TEST_ASSERT(rc != 0);
-    }
-
-    #if MYNEWT_VAL(SELFTEST)
-    int
-    main(int argc, char **argv)
-    {
-        /* Initialize all packages. */
-        sysinit();
-
-        test_datetime_suite();
-
-        /* Indicate whether all test cases passed. */
-        return tu_any_failed;
-    }
-    #endif
-
-Take a few minutes to review the above code. Then keep reading for some
-specifics.
-
-Asserting
-~~~~~~~~~
-
-The ``test/testutil`` package provides two tools for verifying the
-correctness of a package:
-
--  ``TEST_ASSERT``
--  ``TEST_ASSERT_FATAL``
-
-Both of these macros check if the supplied condition is true. They
-differ in how they behave when the condition is not true. On failure,
-``TEST_ASSERT`` reports the error and proceeds with the remainder of the
-test case. ``TEST_ASSERT_FATAL``, on the other hand, aborts the test
-case on failure.
-
-The general rule is to only use ``TEST_ASSERT_FATAL`` when subsequent
-assertions depend on the condition being checked. For example, when
-``datetime_parse()`` is expected to succeed, the return code is checked
-with ``TEST_ASSERT_FATAL``. If ``datetime_parse()`` unexpectedly failed,
-the contents of the ``tv`` and ``tz`` objects would be indeterminate, so
-it is desirable to abort the test instead of checking them and reporting
-spurious failures.
-
-Scaling Up
-~~~~~~~~~~
-
-The above example is small and self contained, so it is reasonable to
-put everything in a single C file. A typical package will need a lot
-more test code, and it helps to follow some conventions to maintain
-organization. Let's take a look at a more realistic example. Here is the
-directory structure of the ``fs/nffs/test`` package:
-
-::
-
-    fs/nffs/test
-    ??? pkg.yml
-    ??? src
-        ??? nffs_test.c
-        ??? nffs_test.h
-        ??? nffs_test_debug.c
-        ??? nffs_test_priv.h
-        ??? nffs_test_system_01.c
-        ??? nffs_test_utils.c
-        ??? nffs_test_utils.h
-        ??? testcases
-            ??? append_test.c
-            ??? cache_large_file_test.c
-            ??? corrupt_block_test.c
-            ??? corrupt_scratch_test.c
-            ??? gc_on_oom_test.c
-            ??? gc_test.c
-            ??? incomplete_block_test.c
-            ??? large_system_test.c
-            ??? large_unlink_test.c
-            ??? large_write_test.c
-            ??? long_filename_test.c
-            ??? lost_found_test.c
-            ??? many_children_test.c
-            ??? mkdir_test.c
-            ??? open_test.c
-            ??? overwrite_many_test.c
-            ??? overwrite_one_test.c
-            ??? overwrite_three_test.c
-            ??? overwrite_two_test.c
-            ??? read_test.c
-            ??? readdir_test.c
-            ??? rename_test.c
-            ??? split_file_test.c
-            ??? truncate_test.c
-            ??? unlink_test.c
-            ??? wear_level_test.c
-
-The ``fs/nffs/test`` package follows these conventions:
-
-1. A maximum of one test case per C file.
-2. Each test case file goes in the ``testcases`` subdirectory.
-3. Test suites and utility functions go directly in the ``src``
-   directory.
-
-Test packages contributed to the Mynewt project should follow these
-conventions.
-
-Congratulations
----------------
-
-Now you can begin the work of validating your packages.
diff --git a/develop/_sources/os/tutorials/wi-fi_on_arduino.rst.txt b/develop/_sources/os/tutorials/wi-fi_on_arduino.rst.txt
deleted file mode 100644
index 3a381d7e7..000000000
--- a/develop/_sources/os/tutorials/wi-fi_on_arduino.rst.txt
+++ /dev/null
@@ -1,368 +0,0 @@
-Enable Wi-Fi on Arduino MKR1000
--------------------------------
-
-This tutorial shows you how to enable Wi-Fi on an Arduino MKR1000 board
-and connect to a Wi-Fi network.
-
-Prerequisites
-~~~~~~~~~~~~~
-
-Ensure that you have met the following prerequisites before continuing
-with this tutorial:
-
--  Have an Arduino MKR1000 board.
--  Have Internet connectivity to fetch remote Mynewt components.
--  Have a computer to build a Mynewt application and connect to the
-   board over USB.
--  Have a Micro-USB cable to connect the board and the computer.
--  Have local Wi-Fi network that the computer is connected to and that
-   the MKR1000 board can join.
--  Have a `Serial Port Setup </os/get_started/serial_access.html>`__.
--  Have a `Segger J-Link Debug
-   Probe <https://www.segger.com/jlink-debug-probes.html>`__.
--  Have a `J-Link 9 pin Cortex-M
-   Adapter <https://www.segger.com/jlink-adapters.html#CM_9pin>`__ that
-   allows JTAG, SWD and SWO connections between J-Link and Cortex M
-   based target hardware systems
--  Install the `Segger JLINK Software and documentation
-   pack <https://www.segger.com/jlink-software.html>`__.
--  Install the Newt tool and toolchains (See `Basic
-   Setup </os/get_started/get_started.html>`__).
--  Create a project space (directory structure) and populated it with
-   the core code repository (apache-mynewt-core) or know how to as
-   explained in `Creating Your First
-   Project </os/get_started/project_create>`__.
--  Read the Mynewt OS `Concepts </os/get_started/vocabulary.html>`__
-   section.
-
-Create a Project
-~~~~~~~~~~~~~~~~
-
-Create a new project if you do not have an existing one. You can skip
-this step and proceed to `fetch external packages <#%20fetchexternal>`__
-if you already created a project.
-
-Run the following commands to create a new project:
-
-.. code-block:: console
-
-        $ mkdir ~/dev
-        $ cd ~/dev
-        $ newt new arduinowifi
-        Downloading project skeleton from apache/mynewt-blinky...
-        Installing skeleton in arduinowifi...
-        Project arduinowifi successfully created.
-        $ cd arduinowifi
-        $ newt install
-        apache-mynewt-core
-        $
-
-Fetch External Packages
-~~~~~~~~~~~~~~~~~~~~~~~~
-
-Mynewt uses source code provided directly from the chip manufacturer for
-low level operations. Sometimes this code is licensed only for the
-specific manufacturer of the chipset and cannot live in the Apache
-Mynewt repository. That happens to be the case for the Arduino Zero
-board which uses Atmel SAMD21. Runtime's git hub repository hosts such
-external third-party packages and the Newt tool can fetch them.
-
-To fetch the package with MCU support for Atmel SAMD21 for Arduino Zero
-from the Runtime git repository, you need to add the repository to the
-``project.yml`` file in your base project directory.
-
-Mynewt uses source code provided directly from the chip manufacturer for
-low level operations. Sometimes this code is licensed only for the
-specific manufacturer of the chipset and cannot live in the Apache
-Mynewt repository. That happens to be the case for the Arduino Zero
-board which uses Atmel SAMD21. Runtime's github repository hosts such
-external third-party packages and the Newt tool can fetch them.
-
-To fetch the package with MCU support for Atmel SAMD21 for Arduino Zero
-from the Runtime git repository, you need to add the repository to the
-``project.yml`` file in your base project directory (``arduinowifi``).
-
-Here is an example ``project.yml`` file with the Arduino Zero repository
-added. The sections with ``mynewt_arduino_zero`` that need to be added
-to your project file are highlighted.
-
-**Note:** On Windows platforms: You need to set ``vers`` to ``0-dev``
-and use the latest master branch for both repositories.
-
-\`\`\`hl\_lines="6 14 15 16 17 18" $ more project.yml project.name:
-"my\_project"
-
-project.repositories: - apache-mynewt-core - mynewt\_arduino\_zero
-
-repository.apache-mynewt-core: type: github vers: 1-latest user: apache
-repo: mynewt-core
-
-repository.mynewt\_arduino\_zero: type: github vers: 1-latest user:
-runtimeco repo: mynewt\_arduino\_zero $ \`\`\`
-
-Install the project dependencies using the ``newt install`` command
-(you can specify ``-v`` for verbose output):
-
-.. code-block:: console
-
-    $ newt install
-    apache-mynewt-core
-    mynewt_arduino_zero
-    $
-
-**NOTE:** If there has been a new release of a repo used in your project
-since you last installed it, the ``1-latest`` version for the repo in
-the ``project.yml`` file will refer to the new release and will not
-match the installed files. In that case you will get an error message
-saying so and you will need to run ``newt upgrade`` to overwrite the
-existing files with the latest codebase.
-
-Create a Target for the Bootloader
-~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~
-
-You need to create two targets for the MKR1000 board, one for the
-bootloader and one for the ``winc1500_wifi`` application. Run the
-following ``newt target`` commands, from your project directory, to
-create a bootloader target. We name the target ``mkr1000_boot``.
-
-.. code-block:: console
-
-    $ newt target create mkr1000_boot
-    $ newt target set mkr1000_boot bsp=@mynewt_arduino_zero/hw/bsp/arduino_mkr1000
-    $ newt target set mkr1000_boot app=@apache-mynewt-core/apps/boot
-    $ newt target set mkr1000_boot build_profile=optimized
-    $ newt target set mkr1000_boot syscfg=BSP_ARDUINO_ZERO_PRO=1
-
-Create a Target for the Wi-Fi Application
-~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~
-
-Run the following ``newt target`` commands to create a target for the
-``winc1500_wifi`` application in the arduino repository. We name the
-application target ``mkr1000_wifi``.
-
-::
-
-    $ newt target create mkr1000_wifi
-    $ newt target set mkr1000_wifi app=@mynewt_arduino_zero/apps/winc1500_wifi
-    $ newt target set mkr1000_wifi bsp=@mynewt_arduino_zero/hw/bsp/arduino_mkr1000
-    $ newt target set mkr1000_wifi build_profile=debug
-    $ newt target set mkr1000_boot syscfg=BSP_ARDUINO_ZERO_PRO=1
-
-Build the Bootloader
-~~~~~~~~~~~~~~~
-
-
-Run the ``newt build mkr1000_boot`` command to build the bootloader:
-
-.. code-block:: console
-
-    $ newt build mkr1000_boot
-    Building target targets/mkr1000_boot
-    Compiling repos/apache-mynewt-core/boot/bootutil/src/image_rsa.c
-    Compiling repos/apache-mynewt-core/boot/bootutil/src/image_ec256.c
-    Compiling repos/apache-mynewt-core/crypto/mbedtls/src/aes.c
-    Compiling repos/apache-mynewt-core/boot/bootutil/src/image_ec.c
-    Compiling repos/apache-mynewt-core/boot/bootutil/src/image_validate.c
-    Compiling repos/apache-mynewt-core/apps/boot/src/boot.c
-
-           ...
-
-    Archiving util_mem.a
-    Linking ~/dev/arduinowifi/bin/targets/mkr1000_boot/app/apps/boot/boot.elf
-    Target successfully built: targets/mkr1000_boot
-    $
-
-Build the Wi-Fi Application
-~~~~~~~~~~~~~~~~~~~~~~~~~~~
-
-Run the ``newt build mkr1000_wifi`` command to build the wi-fi
-application image:
-
-.. code-block:: console
-
-    $newt build mkr1000_wifi
-    Building target targets/mkr1000_wifi
-    Compiling repos/apache-mynewt-core/boot/bootutil/src/image_ec.c
-    Compiling repos/apache-mynewt-core/boot/bootutil/src/image_ec256.c
-    Compiling repos/apache-mynewt-core/boot/bootutil/src/image_rsa.c
-    Compiling repos/apache-mynewt-core/boot/bootutil/src/image_validate.c
-    Compiling repos/apache-mynewt-core/boot/bootutil/src/loader.c
-               ...
-
-    Archiving util_mem.a
-    Linking ~/dev/arduinowifi/bin/targets/mkr1000_wifi/app/apps/winc1500_wifi/winc1500_wifi.elf
-    Target successfully built: targets/mkr1000_wifi
-    $
-
-Sign and Create the Wi-Fi Application Image
-~~~~~~~~~~~~~~~
-
-
-Run the ``newt create-image mkr1000_wifi 1.0.0`` command to sign and
-create an image file for the Wi-Fi application. You may assign an
-arbitrary version (e.g. 1.0.0) number.
-
-.. code-block:: console
-
-    $newt create-image  mkr1000_wifi 1.0.0
-    Compiling bin/targets/mkr1000_wifi/generated/src/mkr1000_wifi-sysinit-app.c
-    Archiving mkr1000_wifi-sysinit-app.a
-    Linking ~/dev/arduinowifi/bin/targets/mkr1000_wifi/app/apps/winc1500_wifi/winc1500_wifi.elf
-    App image succesfully generated: ~/dev/arduinowifi/bin/targets/mkr1000_wifi/app/apps/winc1500_wifi/winc1500_wifi.img
-    $
-
-Connect to the Board
-~~~~~~~~~~~~~~~~~~~~
-
--  Connect your computer to the MKR1000 board with the Micro-USB cable.
--  Connect the debug probe to the JTAG port on the board using the Jlink
-   9-pin adapter and cable.
-
- |J-Link debug probe to MKR1000|
-
-.. raw:: html
-
-   <p>
-
-Mynewt will download and debug the target through this port. You should
-see a green LED come on and indicates the board has power.
-
-Load the Bootloader onto the Board
-~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~
-
-Run the ``newt load mkr1000_boot`` command to load the bootloader onto
-the board:
-
-.. code-block:: console
-
-    $ newt load mkr1000_boot
-    Loading bootloader
-    $
-
-Load the Wi-Fi Application Image onto the Board
-~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~
-
-Run the ``newt load mkr1000_wifi`` command to load the wifi application
-onto the board:
-
-.. code-block:: console
-
-    $ newt load mkr1000_wifi
-    Loading app image into slot 1
-    $
-
-Setup a Serial Connection Between Your Computer and the Board
-~~~~~~~~~~~~~~~
-
-
-Set up a serial connection from your computer to the MKR1000 board (See
-`Serial Port Setup </os/get_started/serial_access.html>`__). On the
-MKR1000 board, the TX pin is PIN 14 and the RX pin in PIN 13. |Serial
-Connection to MKR1000|
-
-.. raw:: html
-
-   <p>
-
-Locate the port, in the /dev directory on your computer, that the
-serial connection uses. The format of the port name is platform
-dependent:
-
--  Mac OS uses the format ``tty.usbserial-<some identifier>``.
--  Linux uses the format ``TTYUSB<N>``, where ``N`` is a number. For
-   example, TTYUSB2.
--  MinGW on Windows uses the format ``ttyS<N>``, where ``N`` is a
-   number. You must map the port name to a Windows COM port:
-   ``/dev/ttyS<N>`` maps to ``COM<N+1>``. For example, ``/dev/ttyS2``
-   maps to ``COM3``.
-
-   You can also use the Windows Device Manager to find the COM port
-   number.
-
-.. code-block:: console
-
-    $ ls /dev/tty*usbserial*
-    /dev/tty.usbserial-1d13
-    $
-
-Start Wi-Fi via console
-~~~~~~~~~~~~~~~~~~~~~~~
-
-Use a terminal emulation program to communicate with the board over the
-serial port. This tutorial shows a Minicom set up. Run the minicom
-command with the serial port you located on your computer:
-
-**Note:** On Windows, you can use the PuTTY application.
-
-.. code-block:: console
-
-    $ minicom -D /dev/tty.usbserial-1d13 -b 115200
-
-Type ``wifi start`` to start Wi-Fi.
-
-.. code:: hl_lines="11"
-
-
-    Welcome to minicom 2.7.1
-
-    OPTIONS: 
-    Compiled on May 17 2017, 15:29:14.
-    Port /dev/tty.usbserial, 15:12:10
-
-    Press Meta-Z for help on special keys
-
-
-    138465 compat> wifi start
-    144570 compat> (APP)(INFO)Chip ID 1503a0
-    (APP)(INFO)Firmware ver   : 19.4.4
-    (APP)(INFO)Min driver ver : 19.3.0
-    (APP)(INFO)Curr driver ver: 19.3.0
-    wifi_init : 0
-
-Connect to the local Wi-Fi network. Note that the MKR1000 board only
-supports 2.4 GHz Wi-Fi networks.
-
-Run the ``wifi connect`` command and specify your network and . After
-you are connected to your wi-fi network, run the ``net service`` command
-to start network services.
-
-\`\`\`hl\_lines="2 9"
-
-wifi connect 037624 wifi\_request\_scan : 0 037627 compat> scan\_results
-7: 0 038454 wifi\_connect : 0 039451 connect\_done : 0 039958 dhcp done
-192.168.0.135 040169 get sys time response 2017.7.12-22.41.33 net
-service
-
-\`\`\`
-
-The board is connected to the network succesfully and has IP address:
-192.168.0.135
-
-Establish TCP Connection and Talk!
-~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~~
-
-From a terminal on your computer, telnet to ports 7, 9, or 19 using the
-IP address your board has been assigned. Type something on this terminal
-and see the console output (on minicom). Can you see the difference in
-the behaviors?
-
-.. code-block:: console
-
-
-    $telnet  192.168.0.135 7
-    Trying 192.168.0.135...
-    Connected to 192.168.0.135.
-    Escape character is '^]'.
-    hello
-    hello
-    ^]
-    telnet> q
-    $
-
-One port echoes whatever is typed, one discards everything it gets, and
-the third spews out bits constantly. Type ``wifi stop`` to disable WiFi
-on the Arduino board.
-
-.. |J-Link debug probe to MKR1000| image:: pics/mkr1000-jlink.jpg
-.. |Serial Connection to MKR1000| image:: pics/mkr1000-serial.jpg
-
diff --git a/develop/genindex.html b/develop/genindex.html
index 8e37799a7..e8c67f548 100644
--- a/develop/genindex.html
+++ b/develop/genindex.html
@@ -249,12 +249,20 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
 <h1 id="index">Index</h1>
 
 <div class="genindex-jumpbox">
- <a href="#C"><strong>C</strong></a>
+ <a href="#_"><strong>_</strong></a>
+ | <a href="#C"><strong>C</strong></a>
+ | <a href="#H"><strong>H</strong></a>
  | <a href="#O"><strong>O</strong></a>
- | <a href="#S"><strong>S</strong></a>
- | <a href="#T"><strong>T</strong></a>
  
 </div>
+<h2 id="_">_</h2>
+<table style="width: 100%" class="indextable genindextable"><tr>
+  <td style="width: 33%; vertical-align: top;"><ul>
+      <li><a href="os/modules/hal/hal_bsp/hal_bsp.html#c._sbrk">_sbrk (C function)</a>
+</li>
+  </ul></td>
+</tr></table>
+
 <h2 id="C">C</h2>
 <table style="width: 100%" class="indextable genindextable"><tr>
   <td style="width: 33%; vertical-align: top;"><ul>
@@ -287,116 +295,364 @@ <h2 id="C">C</h2>
   </ul></td>
 </tr></table>
 
-<h2 id="O">O</h2>
+<h2 id="H">H</h2>
 <table style="width: 100%" class="indextable genindextable"><tr>
   <td style="width: 33%; vertical-align: top;"><ul>
-      <li><a href="os/core_os/API.html#c.os_cputime_delay_nsecs">os_cputime_delay_nsecs (C function)</a>
+      <li><a href="os/modules/hal/hal_bsp/hal_bsp.html#c.hal_bsp_core_dump">hal_bsp_core_dump (C function)</a>
+</li>
+      <li><a href="os/modules/hal/hal_bsp/hal_bsp.html#c.hal_bsp_flash_dev">hal_bsp_flash_dev (C function)</a>
+</li>
+      <li><a href="os/modules/hal/hal_bsp/hal_bsp.html#c.hal_bsp_get_nvic_priority">hal_bsp_get_nvic_priority (C function)</a>
+</li>
+      <li><a href="os/modules/hal/hal_bsp/hal_bsp.html#c.hal_bsp_hw_id">hal_bsp_hw_id (C function)</a>
+</li>
+      <li><a href="os/modules/hal/hal_bsp/hal_bsp.html#c.hal_bsp_init">hal_bsp_init (C function)</a>
+</li>
+      <li><a href="os/modules/hal/hal_bsp/hal_bsp.html#c.hal_bsp_power_state">hal_bsp_power_state (C function)</a>
+</li>
+      <li><a href="os/modules/hal/hal_system/hal_sys.html#c.hal_debugger_connected">hal_debugger_connected (C function)</a>
+</li>
+      <li><a href="os/modules/hal/hal_flash/hal_flash.html#c.hal_flash_align">hal_flash_align (C function)</a>
+</li>
+      <li><a href="os/modules/hal/hal_flash/hal_flash.html#c.hal_flash_erase">hal_flash_erase (C function)</a>
+</li>
+      <li><a href="os/modules/hal/hal_flash/hal_flash.html#c.hal_flash_erase_sector">hal_flash_erase_sector (C function)</a>
+</li>
+      <li><a href="os/modules/hal/hal_flash/hal_flash.html#c.hal_flash_init">hal_flash_init (C function)</a>
+</li>
+      <li><a href="os/modules/hal/hal_flash/hal_flash.html#c.hal_flash_ioctl">hal_flash_ioctl (C function)</a>
 </li>
-      <li><a href="os/core_os/API.html#c.os_cputime_delay_ticks">os_cputime_delay_ticks (C function)</a>
+      <li><a href="os/modules/hal/hal_flash/hal_flash.html#c.hal_flash_read">hal_flash_read (C function)</a>
 </li>
-      <li><a href="os/core_os/API.html#c.os_cputime_delay_usecs">os_cputime_delay_usecs (C function)</a>
+      <li><a href="os/modules/hal/hal_flash/hal_flash.html#c.hal_flash_write">hal_flash_write (C function)</a>
 </li>
-      <li><a href="os/core_os/API.html#c.os_cputime_get32">os_cputime_get32 (C function)</a>
+      <li><a href="os/modules/hal/hal_gpio/hal_gpio.html#c.hal_gpio_init_in">hal_gpio_init_in (C function)</a>
 </li>
-      <li><a href="os/core_os/API.html#c.os_cputime_init">os_cputime_init (C function)</a>
+      <li><a href="os/modules/hal/hal_gpio/hal_gpio.html#c.hal_gpio_init_out">hal_gpio_init_out (C function)</a>
 </li>
-      <li><a href="os/core_os/API.html#c.os_cputime_nsecs_to_ticks">os_cputime_nsecs_to_ticks (C function)</a>
+      <li><a href="os/modules/hal/hal_gpio/hal_gpio.html#c.hal_gpio_irq_disable">hal_gpio_irq_disable (C function)</a>
 </li>
-      <li><a href="os/core_os/API.html#c.os_cputime_ticks_to_nsecs">os_cputime_ticks_to_nsecs (C function)</a>
+      <li><a href="os/modules/hal/hal_gpio/hal_gpio.html#c.hal_gpio_irq_enable">hal_gpio_irq_enable (C function)</a>
 </li>
-      <li><a href="os/core_os/API.html#c.os_cputime_ticks_to_usecs">os_cputime_ticks_to_usecs (C function)</a>
+      <li><a href="os/modules/hal/hal_gpio/hal_gpio.html#c.hal_gpio_irq_init">hal_gpio_irq_init (C function)</a>
 </li>
-      <li><a href="os/core_os/API.html#c.os_cputime_timer_init">os_cputime_timer_init (C function)</a>
+      <li><a href="os/modules/hal/hal_gpio/hal_gpio.html#c.hal_gpio_irq_release">hal_gpio_irq_release (C function)</a>
 </li>
-      <li><a href="os/core_os/API.html#c.os_cputime_timer_relative">os_cputime_timer_relative (C function)</a>
+      <li><a href="os/modules/hal/hal_gpio/hal_gpio.html#c.hal_gpio_read">hal_gpio_read (C function)</a>
 </li>
-      <li><a href="os/core_os/API.html#c.os_cputime_timer_start">os_cputime_timer_start (C function)</a>
+      <li><a href="os/modules/hal/hal_gpio/hal_gpio.html#c.hal_gpio_toggle">hal_gpio_toggle (C function)</a>
 </li>
-      <li><a href="os/core_os/API.html#c.os_cputime_timer_stop">os_cputime_timer_stop (C function)</a>
+      <li><a href="os/modules/hal/hal_gpio/hal_gpio.html#c.hal_gpio_write">hal_gpio_write (C function)</a>
 </li>
-      <li><a href="os/core_os/API.html#c.os_cputime_usecs_to_ticks">os_cputime_usecs_to_ticks (C function)</a>
+      <li><a href="os/modules/hal/hal_i2c/hal_i2c.html#c.hal_i2c_init">hal_i2c_init (C function)</a>
 </li>
-      <li><a href="os/core_os/API.html#c.os_get_uptime_usec">os_get_uptime_usec (C function)</a>
+      <li><a href="os/modules/hal/hal_i2c/hal_i2c.html#_CPPv319hal_i2c_master_data">hal_i2c_master_data (C++ class)</a>
 </li>
-      <li><a href="os/core_os/API.html#c.os_gettimeofday">os_gettimeofday (C function)</a>
+      <li><a href="os/modules/hal/hal_i2c/hal_i2c.html#c.hal_i2c_master_probe">hal_i2c_master_probe (C function)</a>
 </li>
-      <li><a href="os/core_os/API.html#c.os_info_init">os_info_init (C function)</a>
+      <li><a href="os/modules/hal/hal_i2c/hal_i2c.html#c.hal_i2c_master_read">hal_i2c_master_read (C function)</a>
 </li>
-      <li><a href="os/core_os/API.html#c.os_init">os_init (C function)</a>
+      <li><a href="os/modules/hal/hal_i2c/hal_i2c.html#c.hal_i2c_master_write">hal_i2c_master_write (C function)</a>
 </li>
-      <li><a href="os/core_os/API.html#c.os_init_idle_task">os_init_idle_task (C function)</a>
+      <li><a href="os/modules/hal/hal_system/hal_sys.html#c.hal_reset_cause">hal_reset_cause (C function)</a>
 </li>
-      <li><a href="os/core_os/API.html#c.os_sched">os_sched (C function)</a>
+      <li><a href="os/modules/hal/hal_spi/hal_spi.html#c.hal_spi_abort">hal_spi_abort (C function)</a>
 </li>
-      <li><a href="os/core_os/API.html#c.os_sched_ctx_sw_hook">os_sched_ctx_sw_hook (C function)</a>
+      <li><a href="os/modules/hal/hal_spi/hal_spi.html#c.hal_spi_config">hal_spi_config (C function)</a>
 </li>
-      <li><a href="os/core_os/API.html#c.os_sched_get_current_task">os_sched_get_current_task (C function)</a>
+      <li><a href="os/modules/hal/hal_spi/hal_spi.html#c.hal_spi_data_mode_breakout">hal_spi_data_mode_breakout (C function)</a>
 </li>
-      <li><a href="os/core_os/API.html#c.os_sched_insert">os_sched_insert (C function)</a>
+      <li><a href="os/modules/hal/hal_spi/hal_spi.html#c.hal_spi_disable">hal_spi_disable (C function)</a>
 </li>
   </ul></td>
   <td style="width: 33%; vertical-align: top;"><ul>
-      <li><a href="os/core_os/API.html#c.os_sched_next_task">os_sched_next_task (C function)</a>
+      <li><a href="os/modules/hal/hal_spi/hal_spi.html#c.hal_spi_enable">hal_spi_enable (C function)</a>
 </li>
-      <li><a href="os/core_os/API.html#c.os_sched_os_timer_exp">os_sched_os_timer_exp (C function)</a>
+      <li><a href="os/modules/hal/hal_spi/hal_spi.html#c.hal_spi_init">hal_spi_init (C function)</a>
 </li>
-      <li><a href="os/core_os/API.html#c.os_sched_remove">os_sched_remove (C function)</a>
+      <li><a href="os/modules/hal/hal_spi/hal_spi.html#c.hal_spi_set_txrx_cb">hal_spi_set_txrx_cb (C function)</a>
 </li>
-      <li><a href="os/core_os/API.html#c.os_sched_resort">os_sched_resort (C function)</a>
+      <li><a href="os/modules/hal/hal_spi/hal_spi.html#_CPPv316hal_spi_settings">hal_spi_settings (C++ class)</a>
 </li>
-      <li><a href="os/core_os/API.html#c.os_sched_set_current_task">os_sched_set_current_task (C function)</a>
+      <li><a href="os/modules/hal/hal_spi/hal_spi.html#c.hal_spi_slave_set_def_tx_val">hal_spi_slave_set_def_tx_val (C function)</a>
 </li>
-      <li><a href="os/core_os/API.html#c.os_sched_sleep">os_sched_sleep (C function)</a>
+      <li><a href="os/modules/hal/hal_spi/hal_spi.html#c.hal_spi_tx_val">hal_spi_tx_val (C function)</a>
 </li>
-      <li><a href="os/core_os/API.html#c.os_sched_wakeup">os_sched_wakeup (C function)</a>
+      <li><a href="os/modules/hal/hal_spi/hal_spi.html#c.hal_spi_txrx">hal_spi_txrx (C function)</a>
 </li>
-      <li><a href="os/core_os/API.html#c.os_sched_wakeup_ticks">os_sched_wakeup_ticks (C function)</a>
+      <li><a href="os/modules/hal/hal_spi/hal_spi.html#c.hal_spi_txrx_noblock">hal_spi_txrx_noblock (C function)</a>
 </li>
-      <li><a href="os/core_os/API.html#c.os_settimeofday">os_settimeofday (C function)</a>
+      <li><a href="os/modules/hal/hal_system/hal_sys.html#c.hal_system_clock_start">hal_system_clock_start (C function)</a>
 </li>
-      <li><a href="os/core_os/API.html#c.os_start">os_start (C function)</a>
+      <li><a href="os/modules/hal/hal_system/hal_sys.html#c.hal_system_reset">hal_system_reset (C function)</a>
 </li>
-      <li><a href="os/core_os/API.html#c.os_started">os_started (C function)</a>
+      <li><a href="os/modules/hal/hal_system/hal_sys.html#c.hal_system_restart">hal_system_restart (C function)</a>
 </li>
-      <li><a href="os/core_os/API.html#c.os_task::SLIST_ENTRY">os_task::SLIST_ENTRY (C function)</a>
+      <li><a href="os/modules/hal/hal_system/hal_sys.html#c.hal_system_start">hal_system_start (C function)</a>
 </li>
-      <li><a href="os/core_os/API.html#c.os_task::STAILQ_ENTRY">os_task::STAILQ_ENTRY (C function)</a>
+      <li><a href="os/modules/hal/hal_timer/hal_timer.html#_CPPv39hal_timer">hal_timer (C++ class)</a>
 </li>
-      <li><a href="os/core_os/API.html#c.os_task::TAILQ_ENTRY">os_task::TAILQ_ENTRY (C function)</a>
+      <li><a href="os/modules/hal/hal_timer/hal_timer.html#c.hal_timer_config">hal_timer_config (C function)</a>
 </li>
-      <li><a href="os/core_os/API.html#c.os_task_count">os_task_count (C function)</a>
+      <li><a href="os/modules/hal/hal_timer/hal_timer.html#c.hal_timer_deinit">hal_timer_deinit (C function)</a>
 </li>
-      <li><a href="os/core_os/API.html#c.os_task_info_get_next">os_task_info_get_next (C function)</a>
+      <li><a href="os/modules/hal/hal_timer/hal_timer.html#c.hal_timer_delay">hal_timer_delay (C function)</a>
 </li>
-      <li><a href="os/core_os/API.html#c.os_task_init">os_task_init (C function)</a>
+      <li><a href="os/modules/hal/hal_timer/hal_timer.html#c.hal_timer_get_resolution">hal_timer_get_resolution (C function)</a>
 </li>
-      <li><a href="os/core_os/API.html#c.os_task_obj::SLIST_HEAD">os_task_obj::SLIST_HEAD (C function)</a>
+      <li><a href="os/modules/hal/hal_timer/hal_timer.html#c.hal_timer_init">hal_timer_init (C function)</a>
 </li>
-      <li><a href="os/core_os/API.html#c.os_task_remove">os_task_remove (C function)</a>
+      <li><a href="os/modules/hal/hal_timer/hal_timer.html#c.hal_timer_read">hal_timer_read (C function)</a>
 </li>
-      <li><a href="os/core_os/API.html#c.os_time_advance">os_time_advance (C function)</a>
+      <li><a href="os/modules/hal/hal_timer/hal_timer.html#c.hal_timer_set_cb">hal_timer_set_cb (C function)</a>
 </li>
-      <li><a href="os/core_os/API.html#c.os_time_delay">os_time_delay (C function)</a>
+      <li><a href="os/modules/hal/hal_timer/hal_timer.html#c.hal_timer_start">hal_timer_start (C function)</a>
 </li>
-      <li><a href="os/core_os/API.html#c.os_time_get">os_time_get (C function)</a>
+      <li><a href="os/modules/hal/hal_timer/hal_timer.html#c.hal_timer_start_at">hal_timer_start_at (C function)</a>
 </li>
-      <li><a href="os/core_os/API.html#c.os_time_ms_to_ticks">os_time_ms_to_ticks (C function)</a>
+      <li><a href="os/modules/hal/hal_timer/hal_timer.html#c.hal_timer_stop">hal_timer_stop (C function)</a>
+</li>
+      <li><a href="os/modules/hal/hal_uart/hal_uart.html#c.hal_uart_blocking_tx">hal_uart_blocking_tx (C function)</a>
+</li>
+      <li><a href="os/modules/hal/hal_uart/hal_uart.html#c.hal_uart_close">hal_uart_close (C function)</a>
+</li>
+      <li><a href="os/modules/hal/hal_uart/hal_uart.html#c.hal_uart_config">hal_uart_config (C function)</a>
+</li>
+      <li><a href="os/modules/hal/hal_uart/hal_uart.html#c.hal_uart_init">hal_uart_init (C function)</a>
+</li>
+      <li><a href="os/modules/hal/hal_uart/hal_uart.html#c.hal_uart_init_cbs">hal_uart_init_cbs (C function)</a>
+</li>
+      <li><a href="os/modules/hal/hal_uart/hal_uart.html#c.hal_uart_start_rx">hal_uart_start_rx (C function)</a>
+</li>
+      <li><a href="os/modules/hal/hal_uart/hal_uart.html#c.hal_uart_start_tx">hal_uart_start_tx (C function)</a>
+</li>
+      <li><a href="os/modules/hal/hal_watchdog/hal_watchdog.html#c.hal_watchdog_enable">hal_watchdog_enable (C function)</a>
+</li>
+      <li><a href="os/modules/hal/hal_watchdog/hal_watchdog.html#c.hal_watchdog_init">hal_watchdog_init (C function)</a>
+</li>
+      <li><a href="os/modules/hal/hal_watchdog/hal_watchdog.html#c.hal_watchdog_tickle">hal_watchdog_tickle (C function)</a>
 </li>
   </ul></td>
 </tr></table>
 
-<h2 id="S">S</h2>
+<h2 id="O">O</h2>
 <table style="width: 100%" class="indextable genindextable"><tr>
   <td style="width: 33%; vertical-align: top;"><ul>
-      <li><a href="os/core_os/API.html#c.STAILQ_HEAD">STAILQ_HEAD (C function)</a>
+      <li><a href="os/core_os/callout/callout.html#_CPPv310os_callout">os_callout (C++ class)</a>
+</li>
+      <li><a href="os/core_os/callout/callout.html#c.os_callout_init">os_callout_init (C function)</a>
+</li>
+      <li><a href="os/core_os/callout/callout.html#c.os_callout_queued">os_callout_queued (C function)</a>
+</li>
+      <li><a href="os/core_os/callout/callout.html#c.os_callout_remaining_ticks">os_callout_remaining_ticks (C function)</a>
+</li>
+      <li><a href="os/core_os/callout/callout.html#c.os_callout_reset">os_callout_reset (C function)</a>
+</li>
+      <li><a href="os/core_os/callout/callout.html#c.os_callout_stop">os_callout_stop (C function)</a>
+</li>
+      <li><a href="os/core_os/cputime/os_cputime.html#c.os_cputime_delay_nsecs">os_cputime_delay_nsecs (C function)</a>
+</li>
+      <li><a href="os/core_os/cputime/os_cputime.html#c.os_cputime_delay_ticks">os_cputime_delay_ticks (C function)</a>
+</li>
+      <li><a href="os/core_os/cputime/os_cputime.html#c.os_cputime_delay_usecs">os_cputime_delay_usecs (C function)</a>
+</li>
+      <li><a href="os/core_os/cputime/os_cputime.html#c.os_cputime_get32">os_cputime_get32 (C function)</a>
+</li>
+      <li><a href="os/core_os/cputime/os_cputime.html#c.os_cputime_init">os_cputime_init (C function)</a>
+</li>
+      <li><a href="os/core_os/cputime/os_cputime.html#c.os_cputime_nsecs_to_ticks">os_cputime_nsecs_to_ticks (C function)</a>
+</li>
+      <li><a href="os/core_os/cputime/os_cputime.html#c.os_cputime_ticks_to_nsecs">os_cputime_ticks_to_nsecs (C function)</a>
+</li>
+      <li><a href="os/core_os/cputime/os_cputime.html#c.os_cputime_ticks_to_usecs">os_cputime_ticks_to_usecs (C function)</a>
+</li>
+      <li><a href="os/core_os/cputime/os_cputime.html#c.os_cputime_timer_init">os_cputime_timer_init (C function)</a>
+</li>
+      <li><a href="os/core_os/cputime/os_cputime.html#c.os_cputime_timer_relative">os_cputime_timer_relative (C function)</a>
+</li>
+      <li><a href="os/core_os/cputime/os_cputime.html#c.os_cputime_timer_start">os_cputime_timer_start (C function)</a>
+</li>
+      <li><a href="os/core_os/cputime/os_cputime.html#c.os_cputime_timer_stop">os_cputime_timer_stop (C function)</a>
+</li>
+      <li><a href="os/core_os/cputime/os_cputime.html#c.os_cputime_usecs_to_ticks">os_cputime_usecs_to_ticks (C function)</a>
+</li>
+      <li><a href="os/core_os/event_queue/event_queue.html#_CPPv38os_event">os_event (C++ class)</a>
+</li>
+      <li><a href="os/core_os/event_queue/event_queue.html#_CPPv39os_eventq">os_eventq (C++ class)</a>
+</li>
+      <li><a href="os/core_os/event_queue/event_queue.html#c.os_eventq_dflt_get">os_eventq_dflt_get (C function)</a>
+</li>
+      <li><a href="os/core_os/event_queue/event_queue.html#c.os_eventq_get">os_eventq_get (C function)</a>
+</li>
+      <li><a href="os/core_os/event_queue/event_queue.html#c.os_eventq_get_no_wait">os_eventq_get_no_wait (C function)</a>
+</li>
+      <li><a href="os/core_os/event_queue/event_queue.html#c.os_eventq_init">os_eventq_init (C function)</a>
+</li>
+      <li><a href="os/core_os/event_queue/event_queue.html#c.os_eventq_inited">os_eventq_inited (C function)</a>
+</li>
+      <li><a href="os/core_os/event_queue/event_queue.html#c.os_eventq_poll">os_eventq_poll (C function)</a>
+</li>
+      <li><a href="os/core_os/event_queue/event_queue.html#c.os_eventq_put">os_eventq_put (C function)</a>
+</li>
+      <li><a href="os/core_os/event_queue/event_queue.html#c.os_eventq_remove">os_eventq_remove (C function)</a>
+</li>
+      <li><a href="os/core_os/event_queue/event_queue.html#c.os_eventq_run">os_eventq_run (C function)</a>
+</li>
+      <li><a href="os/core_os/time/os_time.html#c.os_get_uptime_usec">os_get_uptime_usec (C function)</a>
+</li>
+      <li><a href="os/core_os/time/os_time.html#c.os_gettimeofday">os_gettimeofday (C function)</a>
+</li>
+      <li><a href="os/core_os/mbuf/mbuf.html#_CPPv37os_mbuf">os_mbuf (C++ class)</a>
+</li>
+      <li><a href="os/core_os/mbuf/mbuf.html#c.os_mbuf_adj">os_mbuf_adj (C function)</a>
+</li>
+      <li><a href="os/core_os/mbuf/mbuf.html#c.os_mbuf_append">os_mbuf_append (C function)</a>
+</li>
+      <li><a href="os/core_os/mbuf/mbuf.html#c.os_mbuf_appendfrom">os_mbuf_appendfrom (C function)</a>
+</li>
+      <li><a href="os/core_os/mbuf/mbuf.html#c.os_mbuf_cmpf">os_mbuf_cmpf (C function)</a>
+</li>
+      <li><a href="os/core_os/mbuf/mbuf.html#c.os_mbuf_cmpm">os_mbuf_cmpm (C function)</a>
+</li>
+      <li><a href="os/core_os/mbuf/mbuf.html#c.os_mbuf_concat">os_mbuf_concat (C function)</a>
+</li>
+      <li><a href="os/core_os/mbuf/mbuf.html#c.os_mbuf_copydata">os_mbuf_copydata (C function)</a>
+</li>
+      <li><a href="os/core_os/mbuf/mbuf.html#c.os_mbuf_copyinto">os_mbuf_copyinto (C function)</a>
+</li>
+      <li><a href="os/core_os/mbuf/mbuf.html#c.os_mbuf_dup">os_mbuf_dup (C function)</a>
+</li>
+      <li><a href="os/core_os/mbuf/mbuf.html#c.os_mbuf_extend">os_mbuf_extend (C function)</a>
+</li>
+      <li><a href="os/core_os/mbuf/mbuf.html#c.os_mbuf_free">os_mbuf_free (C function)</a>
+</li>
+      <li><a href="os/core_os/mbuf/mbuf.html#c.os_mbuf_free_chain">os_mbuf_free_chain (C function)</a>
+</li>
+      <li><a href="os/core_os/mbuf/mbuf.html#c.os_mbuf_get">os_mbuf_get (C function)</a>
+</li>
+      <li><a href="os/core_os/mbuf/mbuf.html#c.os_mbuf_get_pkthdr">os_mbuf_get_pkthdr (C function)</a>
+</li>
+      <li><a href="os/core_os/mbuf/mbuf.html#c.os_mbuf_off">os_mbuf_off (C function)</a>
+</li>
+      <li><a href="os/core_os/mbuf/mbuf.html#_CPPv314os_mbuf_pkthdr">os_mbuf_pkthdr (C++ class)</a>
+</li>
+      <li><a href="os/core_os/mbuf/mbuf.html#_CPPv312os_mbuf_pool">os_mbuf_pool (C++ class)</a>
+</li>
+      <li><a href="os/core_os/mbuf/mbuf.html#c.os_mbuf_pool_init">os_mbuf_pool_init (C function)</a>
+</li>
+      <li><a href="os/core_os/mbuf/mbuf.html#c.os_mbuf_prepend">os_mbuf_prepend (C function)</a>
+</li>
+      <li><a href="os/core_os/mbuf/mbuf.html#c.os_mbuf_prepend_pullup">os_mbuf_prepend_pullup (C function)</a>
 </li>
   </ul></td>
-</tr></table>
-
-<h2 id="T">T</h2>
-<table style="width: 100%" class="indextable genindextable"><tr>
   <td style="width: 33%; vertical-align: top;"><ul>
-      <li><a href="os/core_os/API.html#c.TAILQ_HEAD">TAILQ_HEAD (C function)</a>
+      <li><a href="os/core_os/mbuf/mbuf.html#c.os_mbuf_pullup">os_mbuf_pullup (C function)</a>
+</li>
+      <li><a href="os/core_os/mbuf/mbuf.html#c.os_mbuf_trim_front">os_mbuf_trim_front (C function)</a>
+</li>
+      <li><a href="os/core_os/memory_pool/memory_pool.html#_CPPv311os_memblock">os_memblock (C++ class)</a>
+</li>
+      <li><a href="os/core_os/memory_pool/memory_pool.html#c.os_memblock_from">os_memblock_from (C function)</a>
+</li>
+      <li><a href="os/core_os/memory_pool/memory_pool.html#c.os_memblock_get">os_memblock_get (C function)</a>
+</li>
+      <li><a href="os/core_os/memory_pool/memory_pool.html#c.os_memblock_put">os_memblock_put (C function)</a>
+</li>
+      <li><a href="os/core_os/memory_pool/memory_pool.html#c.os_memblock_put_from_cb">os_memblock_put_from_cb (C function)</a>
+</li>
+      <li><a href="os/core_os/memory_pool/memory_pool.html#_CPPv310os_mempool">os_mempool (C++ class)</a>
+</li>
+      <li><a href="os/core_os/memory_pool/memory_pool.html#c.os_mempool_ext_init">os_mempool_ext_init (C function)</a>
+</li>
+      <li><a href="os/core_os/memory_pool/memory_pool.html#_CPPv315os_mempool_info">os_mempool_info (C++ class)</a>
+</li>
+      <li><a href="os/core_os/memory_pool/memory_pool.html#c.os_mempool_info_get_next">os_mempool_info_get_next (C function)</a>
+</li>
+      <li><a href="os/core_os/memory_pool/memory_pool.html#c.os_mempool_init">os_mempool_init (C function)</a>
+</li>
+      <li><a href="os/core_os/memory_pool/memory_pool.html#c.os_mempool_is_sane">os_mempool_is_sane (C function)</a>
+</li>
+      <li><a href="os/core_os/mbuf/mbuf.html#_CPPv39os_mqueue">os_mqueue (C++ class)</a>
+</li>
+      <li><a href="os/core_os/mbuf/mbuf.html#c.os_mqueue_get">os_mqueue_get (C function)</a>
+</li>
+      <li><a href="os/core_os/mbuf/mbuf.html#c.os_mqueue_init">os_mqueue_init (C function)</a>
+</li>
+      <li><a href="os/core_os/mbuf/mbuf.html#c.os_mqueue_put">os_mqueue_put (C function)</a>
+</li>
+      <li><a href="os/core_os/mbuf/mbuf.html#c.os_msys_count">os_msys_count (C function)</a>
+</li>
+      <li><a href="os/core_os/mbuf/mbuf.html#c.os_msys_get">os_msys_get (C function)</a>
+</li>
+      <li><a href="os/core_os/mbuf/mbuf.html#c.os_msys_get_pkthdr">os_msys_get_pkthdr (C function)</a>
+</li>
+      <li><a href="os/core_os/mbuf/mbuf.html#c.os_msys_num_free">os_msys_num_free (C function)</a>
+</li>
+      <li><a href="os/core_os/mbuf/mbuf.html#c.os_msys_register">os_msys_register (C function)</a>
+</li>
+      <li><a href="os/core_os/mbuf/mbuf.html#c.os_msys_reset">os_msys_reset (C function)</a>
+</li>
+      <li><a href="os/core_os/mutex/mutex.html#_CPPv38os_mutex">os_mutex (C++ class)</a>
+</li>
+      <li><a href="os/core_os/mutex/mutex.html#c.os_mutex::SLIST_HEAD">os_mutex::SLIST_HEAD (C function)</a>
+</li>
+      <li><a href="os/core_os/mutex/mutex.html#c.os_mutex_init">os_mutex_init (C function)</a>
+</li>
+      <li><a href="os/core_os/mutex/mutex.html#c.os_mutex_pend">os_mutex_pend (C function)</a>
+</li>
+      <li><a href="os/core_os/mutex/mutex.html#c.os_mutex_release">os_mutex_release (C function)</a>
+</li>
+      <li><a href="os/core_os/sanity/sanity.html#_CPPv315os_sanity_check">os_sanity_check (C++ class)</a>
+</li>
+      <li><a href="os/core_os/sanity/sanity.html#c.os_sanity_check_init">os_sanity_check_init (C function)</a>
+</li>
+      <li><a href="os/core_os/sanity/sanity.html#c.os_sanity_check_register">os_sanity_check_register (C function)</a>
+</li>
+      <li><a href="os/core_os/sanity/sanity.html#c.os_sanity_check_reset">os_sanity_check_reset (C function)</a>
+</li>
+      <li><a href="os/core_os/sanity/sanity.html#c.os_sanity_task_checkin">os_sanity_task_checkin (C function)</a>
+</li>
+      <li><a href="os/core_os/context_switch/context_switch.html#c.os_sched_get_current_task">os_sched_get_current_task (C function)</a>
+</li>
+      <li><a href="os/core_os/semaphore/semaphore.html#_CPPv36os_sem">os_sem (C++ class)</a>
+</li>
+      <li><a href="os/core_os/semaphore/semaphore.html#c.os_sem_get_count">os_sem_get_count (C function)</a>
+</li>
+      <li><a href="os/core_os/semaphore/semaphore.html#c.os_sem_init">os_sem_init (C function)</a>
+</li>
+      <li><a href="os/core_os/semaphore/semaphore.html#c.os_sem_pend">os_sem_pend (C function)</a>
+</li>
+      <li><a href="os/core_os/semaphore/semaphore.html#c.os_sem_release">os_sem_release (C function)</a>
+</li>
+      <li><a href="os/core_os/time/os_time.html#c.os_settimeofday">os_settimeofday (C function)</a>
+</li>
+      <li><a href="os/core_os/task/task.html#_CPPv37os_task">os_task (C++ class)</a>
+</li>
+      <li><a href="os/core_os/task/task.html#c.os_task_count">os_task_count (C function)</a>
+</li>
+      <li><a href="os/core_os/task/task.html#_CPPv312os_task_info">os_task_info (C++ class)</a>
+</li>
+      <li><a href="os/core_os/task/task.html#c.os_task_info_get_next">os_task_info_get_next (C function)</a>
+</li>
+      <li><a href="os/core_os/task/task.html#c.os_task_init">os_task_init (C function)</a>
+</li>
+      <li><a href="os/core_os/task/task.html#c.os_task_remove">os_task_remove (C function)</a>
+</li>
+      <li><a href="os/modules/hal/hal_os_tick/hal_os_tick.html#c.os_tick_idle">os_tick_idle (C function)</a>
+</li>
+      <li><a href="os/modules/hal/hal_os_tick/hal_os_tick.html#c.os_tick_init">os_tick_init (C function)</a>
+</li>
+      <li><a href="os/core_os/time/os_time.html#c.os_time_advance">os_time_advance (C function)</a>
+</li>
+      <li><a href="os/core_os/time/os_time.html#c.os_time_delay">os_time_delay (C function)</a>
+</li>
+      <li><a href="os/core_os/time/os_time.html#c.os_time_get">os_time_get (C function)</a>
+</li>
+      <li><a href="os/core_os/time/os_time.html#c.os_time_ms_to_ticks">os_time_ms_to_ticks (C function)</a>
+</li>
+      <li><a href="os/core_os/time/os_time.html#_CPPv310os_timeval">os_timeval (C++ class)</a>
+</li>
+      <li><a href="os/core_os/time/os_time.html#_CPPv311os_timezone">os_timezone (C++ class)</a>
 </li>
   </ul></td>
 </tr></table>
diff --git a/develop/misc/faq.html b/develop/misc/faq.html
index f0b8c5830..650221df4 100644
--- a/develop/misc/faq.html
+++ b/develop/misc/faq.html
@@ -271,7 +271,7 @@ <h2>Mynewt software questions:<a class="headerlink" href="#mynewt-software-quest
 </div>
 <div class="section" id="how-do-i-reduce-the-code-size-for-my-mynewt-image">
 <h3><a class="toc-backref" href="#id2">How do I reduce the code size for my Mynewt image?</a><a class="headerlink" href="#how-do-i-reduce-the-code-size-for-my-mynewt-image" title="Permalink to this headline">?</a></h3>
-<p>Please refer to the tutorial documentation on <a class="reference external" href="https://github.com/apache/mynewt-site/blob/master/docs/os/tutorials/codesize.md">reducing application code size</a>.</p>
+<p>Please refer to the tutorial documentation on <a class="reference internal" href="../tutorials/other/codesize.html"><span class="doc">reducing application code size</span></a>.</p>
 </div>
 <div class="section" id="i-m-having-issues-using-newt-manager-with-the-adafruit-nrf52dk-what-do-i-do">
 <h3><a class="toc-backref" href="#id3">I?m having issues using Newt Manager with the Adafruit nRF52DK. What do I do?</a><a class="headerlink" href="#i-m-having-issues-using-newt-manager-with-the-adafruit-nrf52dk-what-do-i-do" title="Permalink to this headline">?</a></h3>
diff --git a/develop/network/ble/ble_intro.html b/develop/network/ble/ble_intro.html
index 216be1b82..36594f8a0 100644
--- a/develop/network/ble/ble_intro.html
+++ b/develop/network/ble/ble_intro.html
@@ -42,7 +42,7 @@
           <link rel="search" title="Search" href="../../search.html"/>
       <link rel="top" title="Apache Mynewt 1.3.0 documentation" href="../../index.html"/>
           <link rel="next" title="NimBLE Security" href="ble_sec.html"/>
-          <link rel="prev" title="Validation and Error Messages" href="../../os/modules/sysinitconfig/sysconfig_error.html"/> 
+          <link rel="prev" title="Console" href="../../os/modules/console/console.html"/> 
 
     
     <script src="../../_static/js/modernizr.min.js"></script>
@@ -382,7 +382,7 @@ <h2><a class="toc-backref" href="#id4">Example NimBLE projects</a><a class="head
         <a href="ble_sec.html" class="btn btn-neutral float-right" title="NimBLE Security" accesskey="n">Next: NimBLE Security <span class="fa fa-arrow-circle-right"></span></a>
       
       
-        <a href="../../os/modules/sysinitconfig/sysconfig_error.html" class="btn btn-neutral" title="Validation and Error Messages" accesskey="p"><span class="fa fa-arrow-circle-left"></span> Previous: Validation and Error Messages</a>
+        <a href="../../os/modules/console/console.html" class="btn btn-neutral" title="Console" accesskey="p"><span class="fa fa-arrow-circle-left"></span> Previous: Console</a>
       
     </div>
 
diff --git a/develop/objects.inv b/develop/objects.inv
index ff7a5ab04..57dda76c9 100644
Binary files a/develop/objects.inv and b/develop/objects.inv differ
diff --git a/develop/os/core_os/API.html b/develop/os/core_os/API.html
deleted file mode 100644
index 8ab3e8a78..000000000
--- a/develop/os/core_os/API.html
+++ /dev/null
@@ -1,1227 +0,0 @@
-
-
-<!DOCTYPE html>
-<html lang="en">
-  <head>
-    <meta charset="utf-8">
-    <meta http-equiv="X-UA-Compatible" content="IE=edge">
-    <meta name="viewport" content="width=device-width, initial-scale=1.0">
-
-    
-
-    
-    <title>Core OS API &mdash; Apache Mynewt 1.3.0 documentation</title>
-    
-
-    
-    
-      <link rel="shortcut icon" href="../../_static/mynewt-logo-only-newt32x32.png"/>
-    
-
-    
-
-    <link rel="stylesheet" href="../../_static/css/theme.css" type="text/css" />
-
-    
-      <link rel="stylesheet" href="../../_static/css/sphinx_theme.css" type="text/css" />
-    
-      <link rel="stylesheet" href="../../_static/css/bootstrap-3.0.3.min.css" type="text/css" />
-    
-      <link rel="stylesheet" href="../../_static/css/v2.css" type="text/css" />
-    
-      <link rel="stylesheet" href="../../_static/css/custom.css" type="text/css" />
-    
-      <link rel="stylesheet" href="../../_static/css/restructuredtext.css" type="text/css" />
-    
-
-    
-
-    <link rel="stylesheet" href="../../_static/css/overrides.css" type="text/css" />
-          <link rel="index" title="Index"
-                href="../../genindex.html"/>
-          <link rel="search" title="Search" href="../../search.html"/>
-      <link rel="top" title="Apache Mynewt 1.3.0 documentation" href="../../index.html"/>
-          <link rel="up" title="Mynewt Core OS" href="mynewt_os.html"/>
-          <link rel="next" title="Porting Mynewt OS" href="porting/port_os.html"/>
-          <link rel="prev" title="Callout" href="callout/callout.html"/> 
-
-    
-    <script src="../../_static/js/modernizr.min.js"></script>
-
-    
-    <script>
-    (function(i, s, o, g, r, a, m) {
-	i["GoogleAnalyticsObject"] = r;
-	(i[r] =
-		i[r] ||
-		function() {
-			(i[r].q = i[r].q || []).push(arguments);
-		}),
-		(i[r].l = 1 * new Date());
-	(a = s.createElement(o)), (m = s.getElementsByTagName(o)[0]);
-	a.async = 1;
-	a.src = g;
-	m.parentNode.insertBefore(a, m);
-})(window, document, "script", "//www.google-analytics.com/analytics.js", "ga");
-
-ga("create", "UA-72162311-1", "auto");
-ga("send", "pageview");
-</script>
-    
-
-  </head>
-
-  <body class="not-front page-documentation" role="document" >
-    <div id="wrapper">
-      <div class="container">
-    <div id="banner" class="row v2-main-banner">
-        <a class="logo-cell" href="/">
-            <img class="logo" src="../../_static/img/logo.png">
-        </a>
-        <div class="tagline-cell">
-            <h4 class="tagline">An OS to build, deploy and securely manage billions of devices</h4>
-        </div>
-        <div class="news-cell">
-            <div class="well">
-              <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (December 13, 2017)
-            </div>
-        </div>
-    </div>
-</div>
-      
-<header>
-    <nav id="navbar" class="navbar navbar-inverse" role="navigation">
-        <div class="container">
-            <!-- Collapsed navigation -->
-            <div class="navbar-header">
-                <!-- Expander button -->
-                <button type="button" class="navbar-toggle" data-toggle="collapse" data-target=".navbar-collapse">
-                    <span class="sr-only">Toggle navigation</span>
-                    <span class="icon-bar"></span>
-                    <span class="icon-bar"></span>
-                    <span class="icon-bar"></span>
-                </button>
-
-            </div>
-
-            <!-- Expanded navigation -->
-            <div class="navbar-collapse collapse">
-                <!-- Main navigation -->
-                <ul class="nav navbar-nav navbar-right">
-                    <li>
-                        <a href="/"><i class="fa fa-home" style="font-size: larger;"></i></a>
-                    </li>
-                    <li class="important">
-                        <a href="/get_started/quick_start.html">Quick Start</a>
-                    </li>
-                    <li>
-                        <a href="/about/">About</a>
-                    </li>
-                    <li>
-                        <a href="/talks/">Talks</a>
-                    </li>
-                    <li class="active">
-                        <a href="/documentation/">Documentation</a>
-                    </li>
-                    <li>
-                        <a href="/download/">Download</a>
-                    </li>
-                    <li>
-                        <a href="/community/">Community</a>
-                    </li>
-                    <li>
-                        <a href="/events/">Events</a>
-                    </li>
-                </ul>
-
-                <!-- Search, Navigation and Repo links -->
-                <ul class="nav navbar-nav navbar-right">
-                    
-                </ul>
-            </div>
-        </div>
-    </nav>
-</header>
-      <!-- STARTS MAIN CONTENT -->
-      <div id="main-content">
-        
-
-
-
-
-
-<div id="breadcrumb">
-  <div class="container">
-    <a href="/documentation/">Docs</a> /
-    
-      <a href="../os_user_guide.html">OS User Guide</a> /
-    
-      <a href="mynewt_os.html">Mynewt Core OS</a> /
-    
-    Core OS API
-    
-  <div class="sourcelink">
-    <a href="https://github.com/apache/mynewt-core/edit/master/docs/os/core_os/API.rst" class="icon icon-github"
-           rel="nofollow"> Edit on GitHub</a>
-</div>
-  </div>
-</div>
-        <!-- STARTS CONTAINER -->
-        <div class="container">
-          <!-- STARTS .content -->
-          <div id="content" class="row">
-            
-            <!-- STARTS .container-sidebar -->
-<div class="container-sidebar col-xs-12 col-sm-3">
-  <div id="docSidebar" class="sticky-container">
-    <div role="search" class="sphinx-search">
-  <form id="rtd-search-form" class="wy-form" action="../../search.html" method="get">
-    <input type="text" name="q" placeholder="Search documentation" class="search-documentation" />
-    <input type="hidden" name="check_keywords" value="yes" />
-    <input type="hidden" name="area" value="default" />
-  </form>
-</div>
-    
-<!-- Note: only works when deployed -->
-<select class="form-control" onchange="if (this.value) window.location.href=this.value">
-    <option
-      value="/develop"
-      selected
-      >
-      Version: develop (latest - mynewt-documentation)
-    </option>
-    <option
-      value="/latest/os/introduction"
-      >
-      Version: master (latest - mynewt-site)
-    </option>
-    <option
-      value="/v1_2_0/os/introduction"
-      >
-      Version: 1.2.0
-    </option>
-    <option
-      value="/v1_1_0/os/introduction">
-      Version: 1.1.0
-    </option>
-    <option
-      value="/v1_0_0/os/introduction">
-      Version: 1.0.0
-    </option>
-    <option
-      value="/v0_9_0/os/introduction">
-      Version: 0_9_0
-    </option>
-</select>
-    <div class="region region-sidebar">
-      <div class="docs-menu">
-      
-        
-        
-            <ul class="current">
-<li class="toctree-l1"><a class="reference internal" href="../../index.html">Introduction</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../get_started/index.html">Setup &amp; Get Started</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../concepts.html">Concepts</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../tutorials/tutorials.html">Tutorials</a></li>
-<li class="toctree-l1 current"><a class="reference internal" href="../os_user_guide.html">OS User Guide</a><ul class="current">
-<li class="toctree-l2 current"><a class="reference internal" href="mynewt_os.html">OS Core</a><ul class="current">
-<li class="toctree-l3"><a class="reference internal" href="context_switch/context_switch.html">Scheduler</a></li>
-<li class="toctree-l3"><a class="reference internal" href="cputime/os_cputime.html">CPU Time</a></li>
-<li class="toctree-l3"><a class="reference internal" href="time/os_time.html">OS Time</a></li>
-<li class="toctree-l3"><a class="reference internal" href="task/task.html">Task</a></li>
-<li class="toctree-l3"><a class="reference internal" href="event_queue/event_queue.html">Event Queues</a></li>
-<li class="toctree-l3"><a class="reference internal" href="semaphore/semaphore.html">Semaphore</a></li>
-<li class="toctree-l3"><a class="reference internal" href="mutex/mutex.html">Mutex</a></li>
-<li class="toctree-l3"><a class="reference internal" href="memory_pool/memory_pool.html">Memory Pools</a></li>
-<li class="toctree-l3"><a class="reference internal" href="heap/heap.html">Heap</a></li>
-<li class="toctree-l3"><a class="reference internal" href="mbuf/mbuf.html">Mbufs</a></li>
-<li class="toctree-l3"><a class="reference internal" href="msys/msys.html">Msys</a></li>
-<li class="toctree-l3"><a class="reference internal" href="mqueue/mqueue.html">Mqueue</a></li>
-<li class="toctree-l3"><a class="reference internal" href="sanity/sanity.html">Sanity</a></li>
-<li class="toctree-l3"><a class="reference internal" href="callout/callout.html">Callout</a></li>
-<li class="toctree-l3 current"><a class="current reference internal" href="#">API</a></li>
-</ul>
-</li>
-<li class="toctree-l2"><a class="reference internal" href="porting/port_os.html">Porting Mynewt OS</a></li>
-<li class="toctree-l2"><a class="reference internal" href="../modules/console/console.html">Console</a></li>
-<li class="toctree-l2"><a class="reference internal" href="../modules/sysinitconfig/sysinitconfig.html">System Configuration and Initialization</a></li>
-</ul>
-</li>
-<li class="toctree-l1"><a class="reference internal" href="../../network/ble/ble_intro.html">BLE User Guide</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../newt/index.html">Newt Tool Guide</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../newtmgr/index.html">Newt Manager Guide</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../misc/index.html">Appendix</a></li>
-</ul>
-
-        
-      
-      </div>
-    </div>
-  </div>
-  <!-- ENDS STICKY CONTAINER -->
-</div>
-<!-- ENDS .container-sidebar -->
-
-            <div class="col-xs-12 col-sm-9">
-              <div class="alert alert-info" role="alert">
-  <p>
-    This is the development version of Apache Mynewt documentation. As such it may not be as complete as the latest
-    stable version of the documentation found <a href="/latest/os/introduction/">here</a>.
-  </p>
-  <p>
-    To improve this documentation please visit <a href="https://github.com/apache/mynewt-documentation">https://github.com/apache/mynewt-documentation</a>.
-  </p>
-</div>
-              
-              <div class="">
-                <div class="rst-content">
-                  <div role="main" class="document" itemscope="itemscope" itemtype="http://schema.org/Article">
-                   <div itemprop="articleBody">
-                    
-  <div class="section" id="core-os-api">
-<h1>Core OS API<a class="headerlink" href="#core-os-api" title="Permalink to this headline">?</a></h1>
-<div class="contents local topic" id="contents">
-<ul class="simple">
-<li><a class="reference internal" href="#core" id="id1">Core</a></li>
-<li><a class="reference internal" href="#scheduler" id="id2">Scheduler</a></li>
-<li><a class="reference internal" href="#cpu-time" id="id3">CPU Time</a></li>
-<li><a class="reference internal" href="#os-time" id="id4">OS Time</a></li>
-<li><a class="reference internal" href="#task" id="id5">Task</a></li>
-</ul>
-</div>
-<div class="section" id="core">
-<h2><a class="toc-backref" href="#id1">Core</a><a class="headerlink" href="#core" title="Permalink to this headline">?</a></h2>
-<div class="breathe-sectiondef docutils container">
-<p class="breathe-sectiondef-title rubric">Defines</p>
-<dl class="define">
-<dt id="c.os_get_return_addr">
-<span class="target" id="os_8h_1a3901120a17c95b6bfd89b6e7a94a9a11"></span><code class="descname">os_get_return_addr</code><a class="headerlink" href="#c.os_get_return_addr" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="define">
-<dt id="c.OS_ALIGN">
-<span class="target" id="os_8h_1a238184fb3d52ded70a2e5025b0f8a3eb"></span><code class="descname">OS_ALIGN</code><span class="sig-paren">(</span>__n, __a<span class="sig-paren">)</span><a class="headerlink" href="#c.OS_ALIGN" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="define">
-<dt id="c.CTASSERT">
-<span class="target" id="os_8h_1a8821cdb56135e0c0b55669242856d15a"></span><code class="descname">CTASSERT</code><span class="sig-paren">(</span>x<span class="sig-paren">)</span><a class="headerlink" href="#c.CTASSERT" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="define">
-<dt id="c.OS_WAIT_FOREVER">
-<span class="target" id="os_8h_1a657765067071658ae82fdd3823fd06e5"></span><code class="descname">OS_WAIT_FOREVER</code><a class="headerlink" href="#c.OS_WAIT_FOREVER" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="define">
-<dt id="c.OS_IDLE_PRIO">
-<span class="target" id="os_8h_1af0c1e6805c77f2eebe6df38f647bdf17"></span><code class="descname">OS_IDLE_PRIO</code><a class="headerlink" href="#c.OS_IDLE_PRIO" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="define">
-<dt id="c.OS_MAIN_TASK_PRIO">
-<span class="target" id="os_8h_1a4812f6ac2b1e24405e1b3bcac5d06ce1"></span><code class="descname">OS_MAIN_TASK_PRIO</code><a class="headerlink" href="#c.OS_MAIN_TASK_PRIO" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="define">
-<dt id="c.OS_MAIN_STACK_SIZE">
-<span class="target" id="os_8h_1acc925f78656654ccfb6dbded48de31ab"></span><code class="descname">OS_MAIN_STACK_SIZE</code><a class="headerlink" href="#c.OS_MAIN_STACK_SIZE" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-</div>
-<div class="breathe-sectiondef docutils container">
-<p class="breathe-sectiondef-title rubric">Functions</p>
-<dl class="function">
-<dt id="c.os_info_init">
-<span class="target" id="os_8h_1a5740bcc0b30b11ae8d03cced4264c4f0"></span>int <code class="descname">os_info_init</code><span class="sig-paren">(</span>void<span class="sig-paren">)</span><a class="headerlink" href="#c.os_info_init" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="function">
-<dt id="c.os_started">
-<span class="target" id="os_8h_1aadf04d8ac4c1cc372411a75dc1ee3392"></span>int <code class="descname">os_started</code><span class="sig-paren">(</span>void<span class="sig-paren">)</span><a class="headerlink" href="#c.os_started" title="Permalink to this definition">?</a></dt>
-<dd><p>Returns 1 if the OS has been started, 0 if it has not yet been been started. </p>
-</dd></dl>
-
-<dl class="function">
-<dt id="c.os_init">
-<span class="target" id="os_8h_1a48e7a787adc974dd92cac6a4d0132e65"></span>void <code class="descname">os_init</code><span class="sig-paren">(</span>int(<em>*fn</em>)(int argc, char **argv)<span class="sig-paren">)</span><a class="headerlink" href="#c.os_init" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="function">
-<dt id="c.os_start">
-<span class="target" id="os_8h_1a19c7111cf2121a69331d99dabe3e9df0"></span>void <code class="descname">os_start</code><span class="sig-paren">(</span>void<span class="sig-paren">)</span><a class="headerlink" href="#c.os_start" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="function">
-<dt id="c.os_init_idle_task">
-<span class="target" id="os_8h_1a32b8cd7ccd96b00a2eec18bcfcddfb51"></span>void <code class="descname">os_init_idle_task</code><span class="sig-paren">(</span>void<span class="sig-paren">)</span><a class="headerlink" href="#c.os_init_idle_task" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-</div>
-<div class="breathe-sectiondef docutils container">
-<p class="breathe-sectiondef-title rubric">Variables</p>
-<dl class="variable">
-<dt id="c.g_os_started">
-<span class="target" id="os_8h_1ac5735e063cf11663546a95d3e16143a3"></span>int <code class="descname">g_os_started</code><a class="headerlink" href="#c.g_os_started" title="Permalink to this definition">?</a></dt>
-<dd><p>Whether or not the operating system has been started. </p>
-<p>Set to 1 right before first task is run. </p>
-</dd></dl>
-
-</div>
-</div>
-<div class="section" id="scheduler">
-<h2><a class="toc-backref" href="#id2">Scheduler</a><a class="headerlink" href="#scheduler" title="Permalink to this headline">?</a></h2>
-<div class="breathe-sectiondef docutils container">
-<p class="breathe-sectiondef-title rubric">Functions</p>
-<dl class="function">
-<dt id="c.TAILQ_HEAD">
-<span class="target" id="group___o_s_sched_1ga1ff6c16f207db29f168ae33b1ac54c70"></span><code class="descname">TAILQ_HEAD</code><span class="sig-paren">(</span>os_task_list, <a class="reference internal" href="#c.os_task" title="os_task">os_task</a><span class="sig-paren">)</span><a class="headerlink" href="#c.TAILQ_HEAD" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="function">
-<dt id="c.os_sched_ctx_sw_hook">
-<span class="target" id="group___o_s_sched_1ga1f553bf004fc39487ebdbf678103ba76"></span>void <code class="descname">os_sched_ctx_sw_hook</code><span class="sig-paren">(</span>struct  <a class="reference internal" href="#c.os_task" title="os_task">os_task</a> <em>&nbsp;*</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_sched_ctx_sw_hook" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="function">
-<dt id="c.os_sched_get_current_task">
-<span class="target" id="group___o_s_sched_1gae76543413dbb2abc71c8236da4e93cfb"></span>struct <a class="reference internal" href="#c.os_task" title="os_task">os_task</a>* <code class="descname">os_sched_get_current_task</code><span class="sig-paren">(</span>void<span class="sig-paren">)</span><a class="headerlink" href="#c.os_sched_get_current_task" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="function">
-<dt id="c.os_sched_set_current_task">
-<span class="target" id="group___o_s_sched_1gaf61f1ee217e2f1169f1cb4f34df57a10"></span>void <code class="descname">os_sched_set_current_task</code><span class="sig-paren">(</span>struct  <a class="reference internal" href="#c.os_task" title="os_task">os_task</a> <em>&nbsp;*</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_sched_set_current_task" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="function">
-<dt id="c.os_sched_next_task">
-<span class="target" id="group___o_s_sched_1ga5bb9ddd317310d64f1f85c868ffab923"></span>struct <a class="reference internal" href="#c.os_task" title="os_task">os_task</a>* <code class="descname">os_sched_next_task</code><span class="sig-paren">(</span>void<span class="sig-paren">)</span><a class="headerlink" href="#c.os_sched_next_task" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="function">
-<dt id="c.os_sched">
-<span class="target" id="group___o_s_sched_1gabf7d98a6bb6558a60d1f471736d29ba7"></span>void <code class="descname">os_sched</code><span class="sig-paren">(</span>struct  <a class="reference internal" href="#c.os_task" title="os_task">os_task</a> <em>&nbsp;*</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_sched" title="Permalink to this definition">?</a></dt>
-<dd><p>Performs context switch if needed. </p>
-<p>If next_t is set, that task will be made running. If next_t is NULL, highest priority ready to run is swapped in. This function can be called when new tasks were made ready to run or if the current task is moved to sleeping state.</p>
-<p>This function will call the architecture specific routine to swap in the new task.</p>
-<p><div class="highlight-none notranslate"><div class="highlight"><pre><span></span>// example
-os_error_t
-os_mutex_release(struct os_mutex *mu)
-{
-    ...
-    OS_EXIT_CRITICAL(sr);
-
-    // Re-schedule if needed
-    if (resched) {
-        os_sched(rdy);
-    }
-
-    return OS_OK;
-
-}
-</pre></div>
-</div>
- <dl class="docutils">
-<dt><strong>Return</strong></dt>
-<dd>n/a</dd>
-<dt><strong>Note</strong></dt>
-<dd>Interrupts must be disabled when calling this.</dd>
-<dt><strong>Parameters</strong></dt>
-<dd><ul class="breatheparameterlist first last simple">
-<li><code class="docutils literal notranslate"><span class="pre">next_t</span></code>: Pointer to task which must run next (optional)</li>
-</ul>
-</dd>
-</dl>
-</p>
-</dd></dl>
-
-<dl class="function">
-<dt id="c.os_sched_os_timer_exp">
-<span class="target" id="group___o_s_sched_1ga14f8c0ca99885147ab5e5f3d80145435"></span>void <code class="descname">os_sched_os_timer_exp</code><span class="sig-paren">(</span>void<span class="sig-paren">)</span><a class="headerlink" href="#c.os_sched_os_timer_exp" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="function">
-<dt id="c.os_sched_insert">
-<span class="target" id="group___o_s_sched_1gaed301be511d2dbcb6dd4358b4527328a"></span>os_error_t <code class="descname">os_sched_insert</code><span class="sig-paren">(</span>struct  <a class="reference internal" href="#c.os_task" title="os_task">os_task</a> <em>&nbsp;*</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_sched_insert" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="function">
-<dt id="c.os_sched_sleep">
-<span class="target" id="group___o_s_sched_1ga741fd71239f7f50ad7347f1e2fbea26d"></span>int <code class="descname">os_sched_sleep</code><span class="sig-paren">(</span>struct  <a class="reference internal" href="#c.os_task" title="os_task">os_task</a> <em>&nbsp;*</em>, <a class="reference internal" href="#c.os_time_t" title="os_time_t">os_time_t</a><em>&nbsp;nticks</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_sched_sleep" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="function">
-<dt id="c.os_sched_wakeup">
-<span class="target" id="group___o_s_sched_1gaa3bd3b094a81b93959033e17465934f4"></span>int <code class="descname">os_sched_wakeup</code><span class="sig-paren">(</span>struct  <a class="reference internal" href="#c.os_task" title="os_task">os_task</a> <em>&nbsp;*</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_sched_wakeup" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="function">
-<dt id="c.os_sched_remove">
-<span class="target" id="group___o_s_sched_1ga787ecedb2caeadd5bc483a92110bf6c6"></span>int <code class="descname">os_sched_remove</code><span class="sig-paren">(</span>struct  <a class="reference internal" href="#c.os_task" title="os_task">os_task</a> <em>&nbsp;*</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_sched_remove" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="function">
-<dt id="c.os_sched_resort">
-<span class="target" id="group___o_s_sched_1ga545ee9b359d03e364d7dc4c5fb78e387"></span>void <code class="descname">os_sched_resort</code><span class="sig-paren">(</span>struct  <a class="reference internal" href="#c.os_task" title="os_task">os_task</a> <em>&nbsp;*</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_sched_resort" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="function">
-<dt id="c.os_sched_wakeup_ticks">
-<span class="target" id="group___o_s_sched_1gae64bd12779fcc30e9b0894aa4245559e"></span><a class="reference internal" href="#c.os_time_t" title="os_time_t">os_time_t</a> <code class="descname">os_sched_wakeup_ticks</code><span class="sig-paren">(</span><a class="reference internal" href="#c.os_time_t" title="os_time_t">os_time_t</a><em>&nbsp;now</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_sched_wakeup_ticks" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-</div>
-<div class="breathe-sectiondef docutils container">
-<p class="breathe-sectiondef-title rubric">Variables</p>
-<dl class="variable">
-<dt id="c.g_current_task">
-<span class="target" id="group___o_s_sched_1ga6c8afd9149619e868c72bc8fa960f870"></span>struct <a class="reference internal" href="#c.os_task" title="os_task">os_task</a>* <code class="descname">g_current_task</code><a class="headerlink" href="#c.g_current_task" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="variable">
-<dt id="c.g_os_run_list">
-<span class="target" id="group___o_s_sched_1gaf6cefeec4c776fe0712fd5092cebbf2d"></span>struct os_task_list <code class="descname">g_os_run_list</code><a class="headerlink" href="#c.g_os_run_list" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="variable">
-<dt id="c.g_os_sleep_list">
-<span class="target" id="group___o_s_sched_1ga0cf92117047450a6acdbca41e894dd21"></span>struct os_task_list <code class="descname">g_os_sleep_list</code><a class="headerlink" href="#c.g_os_sleep_list" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-</div>
-</div>
-<div class="section" id="cpu-time">
-<h2><a class="toc-backref" href="#id3">CPU Time</a><a class="headerlink" href="#cpu-time" title="Permalink to this headline">?</a></h2>
-<div class="breathe-sectiondef docutils container">
-<p class="breathe-sectiondef-title rubric">Defines</p>
-<dl class="define">
-<dt id="c.CPUTIME_LT">
-<span class="target" id="group___o_s_c_p_u_time_1ga4309205f199bb636919dbfc5d73ef12e"></span><code class="descname">CPUTIME_LT</code><span class="sig-paren">(</span>__t1, __t2<span class="sig-paren">)</span><a class="headerlink" href="#c.CPUTIME_LT" title="Permalink to this definition">?</a></dt>
-<dd><p>evaluates to true if t1 is before t2 in time </p>
-</dd></dl>
-
-<dl class="define">
-<dt id="c.CPUTIME_GT">
-<span class="target" id="group___o_s_c_p_u_time_1gadad5099542aece9275da4d725eb480ac"></span><code class="descname">CPUTIME_GT</code><span class="sig-paren">(</span>__t1, __t2<span class="sig-paren">)</span><a class="headerlink" href="#c.CPUTIME_GT" title="Permalink to this definition">?</a></dt>
-<dd><p>evaluates to true if t1 is after t2 in time </p>
-</dd></dl>
-
-<dl class="define">
-<dt id="c.CPUTIME_GEQ">
-<span class="target" id="group___o_s_c_p_u_time_1gab2d4411ac9afee90785a47fcb9b0667f"></span><code class="descname">CPUTIME_GEQ</code><span class="sig-paren">(</span>__t1, __t2<span class="sig-paren">)</span><a class="headerlink" href="#c.CPUTIME_GEQ" title="Permalink to this definition">?</a></dt>
-<dd><p>evaluates to true if t1 is after t2 in time </p>
-</dd></dl>
-
-<dl class="define">
-<dt id="c.CPUTIME_LEQ">
-<span class="target" id="group___o_s_c_p_u_time_1gad1fc43d68f68ce9a60261f94864cdfdd"></span><code class="descname">CPUTIME_LEQ</code><span class="sig-paren">(</span>__t1, __t2<span class="sig-paren">)</span><a class="headerlink" href="#c.CPUTIME_LEQ" title="Permalink to this definition">?</a></dt>
-<dd><p>evaluates to true if t1 is on or after t2 in time </p>
-</dd></dl>
-
-</div>
-<div class="breathe-sectiondef docutils container">
-<p class="breathe-sectiondef-title rubric">Functions</p>
-<dl class="function">
-<dt id="c.os_cputime_init">
-<span class="target" id="group___o_s_c_p_u_time_1ga7aa50ce2ac6e1dae6bed02647822f358"></span>int <code class="descname">os_cputime_init</code><span class="sig-paren">(</span>uint32_t<em>&nbsp;clock_freq</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_cputime_init" title="Permalink to this definition">?</a></dt>
-<dd><p>os cputime init </p>
-<p>Initialize the cputime module. This must be called after os_init is called and before any other timer API are used. This should be called only once and should be called before the hardware timer is used.</p>
-<p><dl class="docutils">
-<dt><strong>Return</strong></dt>
-<dd>int 0 on success; -1 on error. </dd>
-<dt><strong>Parameters</strong></dt>
-<dd><ul class="breatheparameterlist first last simple">
-<li><code class="docutils literal notranslate"><span class="pre">clock_freq</span></code>: The desired cputime frequency, in hertz (Hz).</li>
-</ul>
-</dd>
-</dl>
-</p>
-</dd></dl>
-
-<dl class="function">
-<dt id="c.os_cputime_get32">
-<span class="target" id="group___o_s_c_p_u_time_1gafb6a952579e92ce3356df29991aaa9f5"></span>uint32_t <code class="descname">os_cputime_get32</code><span class="sig-paren">(</span>void<span class="sig-paren">)</span><a class="headerlink" href="#c.os_cputime_get32" title="Permalink to this definition">?</a></dt>
-<dd><p>os cputime get32 </p>
-<p>Returns the low 32 bits of cputime.</p>
-<p><dl class="docutils">
-<dt><strong>Return</strong></dt>
-<dd>uint32_t The lower 32 bits of cputime </dd>
-</dl>
-</p>
-</dd></dl>
-
-<dl class="function">
-<dt id="c.os_cputime_nsecs_to_ticks">
-<span class="target" id="group___o_s_c_p_u_time_1gafb439dfff3071b7c294fcf33929470fa"></span>uint32_t <code class="descname">os_cputime_nsecs_to_ticks</code><span class="sig-paren">(</span>uint32_t<em>&nbsp;nsecs</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_cputime_nsecs_to_ticks" title="Permalink to this definition">?</a></dt>
-<dd><p>os cputime nsecs to ticks </p>
-<p>Converts the given number of nanoseconds into cputime ticks.</p>
-<p><dl class="docutils">
-<dt><strong>Return</strong></dt>
-<dd>uint32_t The number of ticks corresponding to ?nsecs? </dd>
-<dt><strong>Parameters</strong></dt>
-<dd><ul class="breatheparameterlist first last simple">
-<li><code class="docutils literal notranslate"><span class="pre">usecs</span></code>: The number of nanoseconds to convert to ticks</li>
-</ul>
-</dd>
-</dl>
-</p>
-</dd></dl>
-
-<dl class="function">
-<dt id="c.os_cputime_ticks_to_nsecs">
-<span class="target" id="group___o_s_c_p_u_time_1ga8643177f7b726a6e16eb9304849b89df"></span>uint32_t <code class="descname">os_cputime_ticks_to_nsecs</code><span class="sig-paren">(</span>uint32_t<em>&nbsp;ticks</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_cputime_ticks_to_nsecs" title="Permalink to this definition">?</a></dt>
-<dd><p>os cputime ticks to nsecs </p>
-<p>Convert the given number of ticks into nanoseconds.</p>
-<p><dl class="docutils">
-<dt><strong>Return</strong></dt>
-<dd>uint32_t The number of nanoseconds corresponding to ?ticks? </dd>
-<dt><strong>Parameters</strong></dt>
-<dd><ul class="breatheparameterlist first last simple">
-<li><code class="docutils literal notranslate"><span class="pre">ticks</span></code>: The number of ticks to convert to nanoseconds.</li>
-</ul>
-</dd>
-</dl>
-</p>
-</dd></dl>
-
-<dl class="function">
-<dt id="c.os_cputime_delay_nsecs">
-<span class="target" id="group___o_s_c_p_u_time_1gab604f54b3bef695127d93738adc09632"></span>void <code class="descname">os_cputime_delay_nsecs</code><span class="sig-paren">(</span>uint32_t<em>&nbsp;nsecs</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_cputime_delay_nsecs" title="Permalink to this definition">?</a></dt>
-<dd><p>os cputime delay nsecs </p>
-<p>Wait until ?nsecs? nanoseconds has elapsed. This is a blocking delay.</p>
-<p><dl class="docutils">
-<dt><strong>Parameters</strong></dt>
-<dd><ul class="breatheparameterlist first last simple">
-<li><code class="docutils literal notranslate"><span class="pre">nsecs</span></code>: The number of nanoseconds to wait. </li>
-</ul>
-</dd>
-</dl>
-</p>
-</dd></dl>
-
-<dl class="function">
-<dt id="c.os_cputime_usecs_to_ticks">
-<span class="target" id="group___o_s_c_p_u_time_1gaa54a2647142c5104ab507da518b7c51a"></span>uint32_t <code class="descname">os_cputime_usecs_to_ticks</code><span class="sig-paren">(</span>uint32_t<em>&nbsp;usecs</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_cputime_usecs_to_ticks" title="Permalink to this definition">?</a></dt>
-<dd><p>os cputime usecs to ticks </p>
-<p>Converts the given number of microseconds into cputime ticks.</p>
-<p><dl class="docutils">
-<dt><strong>Return</strong></dt>
-<dd>uint32_t The number of ticks corresponding to ?usecs? </dd>
-<dt><strong>Parameters</strong></dt>
-<dd><ul class="breatheparameterlist first last simple">
-<li><code class="docutils literal notranslate"><span class="pre">usecs</span></code>: The number of microseconds to convert to ticks</li>
-</ul>
-</dd>
-</dl>
-</p>
-</dd></dl>
-
-<dl class="function">
-<dt id="c.os_cputime_ticks_to_usecs">
-<span class="target" id="group___o_s_c_p_u_time_1ga359fa2d0037720cf7c485c9c2c811a4b"></span>uint32_t <code class="descname">os_cputime_ticks_to_usecs</code><span class="sig-paren">(</span>uint32_t<em>&nbsp;ticks</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_cputime_ticks_to_usecs" title="Permalink to this definition">?</a></dt>
-<dd><p>os cputime ticks to usecs </p>
-<p>Convert the given number of ticks into microseconds.</p>
-<p><dl class="docutils">
-<dt><strong>Return</strong></dt>
-<dd>uint32_t The number of microseconds corresponding to ?ticks? </dd>
-<dt><strong>Parameters</strong></dt>
-<dd><ul class="breatheparameterlist first last simple">
-<li><code class="docutils literal notranslate"><span class="pre">ticks</span></code>: The number of ticks to convert to microseconds.</li>
-</ul>
-</dd>
-</dl>
-</p>
-</dd></dl>
-
-<dl class="function">
-<dt id="c.os_cputime_delay_ticks">
-<span class="target" id="group___o_s_c_p_u_time_1gacb8a96b8a28174810a1d1030abbccc62"></span>void <code class="descname">os_cputime_delay_ticks</code><span class="sig-paren">(</span>uint32_t<em>&nbsp;ticks</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_cputime_delay_ticks" title="Permalink to this definition">?</a></dt>
-<dd><p>os cputime delay ticks </p>
-<p>Wait until the number of ticks has elapsed. This is a blocking delay.</p>
-<p><dl class="docutils">
-<dt><strong>Parameters</strong></dt>
-<dd><ul class="breatheparameterlist first last simple">
-<li><code class="docutils literal notranslate"><span class="pre">ticks</span></code>: The number of ticks to wait. </li>
-</ul>
-</dd>
-</dl>
-</p>
-</dd></dl>
-
-<dl class="function">
-<dt id="c.os_cputime_delay_usecs">
-<span class="target" id="group___o_s_c_p_u_time_1ga5d02f111807229adcbe1a63f6bcd6dfd"></span>void <code class="descname">os_cputime_delay_usecs</code><span class="sig-paren">(</span>uint32_t<em>&nbsp;usecs</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_cputime_delay_usecs" title="Permalink to this definition">?</a></dt>
-<dd><p>os cputime delay usecs </p>
-<p>Wait until ?usecs? microseconds has elapsed. This is a blocking delay.</p>
-<p><dl class="docutils">
-<dt><strong>Parameters</strong></dt>
-<dd><ul class="breatheparameterlist first last simple">
-<li><code class="docutils literal notranslate"><span class="pre">usecs</span></code>: The number of usecs to wait. </li>
-</ul>
-</dd>
-</dl>
-</p>
-</dd></dl>
-
-<dl class="function">
-<dt id="c.os_cputime_timer_init">
-<span class="target" id="group___o_s_c_p_u_time_1gaaa77925d4b99f92de3fdb3a33763f3ee"></span>void <code class="descname">os_cputime_timer_init</code><span class="sig-paren">(</span>struct  hal_timer  *<em>&nbsp;timer</em>, hal_timer_cb<em>&nbsp;fp</em>, void *<em>&nbsp;arg</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_cputime_timer_init" title="Permalink to this definition">?</a></dt>
-<dd><p>os cputime timer init </p>
-<p><dl class="docutils">
-<dt><strong>Parameters</strong></dt>
-<dd><ul class="breatheparameterlist first last simple">
-<li><code class="docutils literal notranslate"><span class="pre">timer</span></code>: The timer to initialize. Cannot be NULL. </li>
-<li><code class="docutils literal notranslate"><span class="pre">fp</span></code>: The timer callback function. Cannot be NULL. </li>
-<li><code class="docutils literal notranslate"><span class="pre">arg</span></code>: Pointer to data object to pass to timer. </li>
-</ul>
-</dd>
-</dl>
-</p>
-</dd></dl>
-
-<dl class="function">
-<dt id="c.os_cputime_timer_start">
-<span class="target" id="group___o_s_c_p_u_time_1ga7ee4efebfb9ace6abc53aab7befbb36b"></span>int <code class="descname">os_cputime_timer_start</code><span class="sig-paren">(</span>struct  hal_timer  *<em>&nbsp;timer</em>, uint32_t<em>&nbsp;cputime</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_cputime_timer_start" title="Permalink to this definition">?</a></dt>
-<dd><p>os cputime timer start </p>
-<p>Start a cputimer that will expire at ?cputime?. If cputime has already passed, the timer callback will still be called (at interrupt context).</p>
-<p>NOTE: This must be called when the timer is stopped.</p>
-<p><dl class="docutils">
-<dt><strong>Return</strong></dt>
-<dd>int 0 on success; EINVAL if timer already started or timer struct invalid </dd>
-<dt><strong>Parameters</strong></dt>
-<dd><ul class="breatheparameterlist first last simple">
-<li><code class="docutils literal notranslate"><span class="pre">timer</span></code>: Pointer to timer to start. Cannot be NULL. </li>
-<li><code class="docutils literal notranslate"><span class="pre">cputime</span></code>: The cputime at which the timer should expire.</li>
-</ul>
-</dd>
-</dl>
-</p>
-</dd></dl>
-
-<dl class="function">
-<dt id="c.os_cputime_timer_relative">
-<span class="target" id="group___o_s_c_p_u_time_1ga178a0ad1206ee2f3921ec812cc4dbd93"></span>int <code class="descname">os_cputime_timer_relative</code><span class="sig-paren">(</span>struct  hal_timer  *<em>&nbsp;timer</em>, uint32_t<em>&nbsp;usecs</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_cputime_timer_relative" title="Permalink to this definition">?</a></dt>
-<dd><p>os cputimer timer relative </p>
-<p>Sets a cpu timer that will expire ?usecs? microseconds from the current cputime.</p>
-<p>NOTE: This must be called when the timer is stopped.</p>
-<p><dl class="docutils">
-<dt><strong>Return</strong></dt>
-<dd>int 0 on success; EINVAL if timer already started or timer struct invalid </dd>
-<dt><strong>Parameters</strong></dt>
-<dd><ul class="breatheparameterlist first last simple">
-<li><code class="docutils literal notranslate"><span class="pre">timer</span></code>: Pointer to timer. Cannot be NULL. </li>
-<li><code class="docutils literal notranslate"><span class="pre">usecs</span></code>: The number of usecs from now at which the timer will expire.</li>
-</ul>
-</dd>
-</dl>
-</p>
-</dd></dl>
-
-<dl class="function">
-<dt id="c.os_cputime_timer_stop">
-<span class="target" id="group___o_s_c_p_u_time_1ga941919d476b402d1afd0d23f1b1e06fe"></span>void <code class="descname">os_cputime_timer_stop</code><span class="sig-paren">(</span>struct  hal_timer  *<em>&nbsp;timer</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_cputime_timer_stop" title="Permalink to this definition">?</a></dt>
-<dd><p>os cputime timer stop </p>
-<p>Stops a cputimer from running. The timer is removed from the timer queue and interrupts are disabled if no timers are left on the queue. Can be called even if timer is not running.</p>
-<p><dl class="docutils">
-<dt><strong>Parameters</strong></dt>
-<dd><ul class="breatheparameterlist first last simple">
-<li><code class="docutils literal notranslate"><span class="pre">timer</span></code>: Pointer to cputimer to stop. Cannot be NULL. </li>
-</ul>
-</dd>
-</dl>
-</p>
-</dd></dl>
-
-</div>
-</div>
-<div class="section" id="os-time">
-<h2><a class="toc-backref" href="#id4">OS Time</a><a class="headerlink" href="#os-time" title="Permalink to this headline">?</a></h2>
-<div class="breathe-sectiondef docutils container">
-<p class="breathe-sectiondef-title rubric">Defines</p>
-<dl class="define">
-<dt id="c.OS_TIME_MAX">
-<span class="target" id="os__time_8h_1a7d9d6efeb91296092166d7f9e1b82cc3"></span><code class="descname">OS_TIME_MAX</code><a class="headerlink" href="#c.OS_TIME_MAX" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="define">
-<dt id="c.OS_TIMEOUT_NEVER">
-<span class="target" id="os__time_8h_1ae28c55062f853e4feb13b3c61a04099c"></span><code class="descname">OS_TIMEOUT_NEVER</code><a class="headerlink" href="#c.OS_TIMEOUT_NEVER" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="define">
-<dt id="c.OS_TIME_TICK_LT">
-<span class="target" id="os__time_8h_1a9ea6181f50d4452091125926891dd6c7"></span><code class="descname">OS_TIME_TICK_LT</code><span class="sig-paren">(</span>__t1, __t2<span class="sig-paren">)</span><a class="headerlink" href="#c.OS_TIME_TICK_LT" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="define">
-<dt id="c.OS_TIME_TICK_GT">
-<span class="target" id="os__time_8h_1acd74602e3bed14014f4e1854aff8bf92"></span><code class="descname">OS_TIME_TICK_GT</code><span class="sig-paren">(</span>__t1, __t2<span class="sig-paren">)</span><a class="headerlink" href="#c.OS_TIME_TICK_GT" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="define">
-<dt id="c.OS_TIME_TICK_GEQ">
-<span class="target" id="os__time_8h_1a3b96d8bc74b2771519ea74c3cc775b58"></span><code class="descname">OS_TIME_TICK_GEQ</code><span class="sig-paren">(</span>__t1, __t2<span class="sig-paren">)</span><a class="headerlink" href="#c.OS_TIME_TICK_GEQ" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="define">
-<dt id="c.os_timeradd">
-<span class="target" id="os__time_8h_1a1e206e1b6cad723bb4bde169cf4f8423"></span><code class="descname">os_timeradd</code><span class="sig-paren">(</span>tvp, uvp, vvp<span class="sig-paren">)</span><a class="headerlink" href="#c.os_timeradd" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="define">
-<dt id="c.os_timersub">
-<span class="target" id="os__time_8h_1a9b5b5bf81fac37a92de28d93ec6d0935"></span><code class="descname">os_timersub</code><span class="sig-paren">(</span>tvp, uvp, vvp<span class="sig-paren">)</span><a class="headerlink" href="#c.os_timersub" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-</div>
-<div class="breathe-sectiondef docutils container">
-<p class="breathe-sectiondef-title rubric">Typedefs</p>
-<dl class="typedef">
-<dt id="c.os_time_t">
-<span class="target" id="os__time_8h_1aa2378cafc0f8fbfb44633036348bfe64"></span><em class="property">typedef </em>uint32_t <code class="descname">os_time_t</code><a class="headerlink" href="#c.os_time_t" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="typedef">
-<dt id="c.os_stime_t">
-<span class="target" id="os__time_8h_1a7557d3ce9091f57daa64e5d3187067f4"></span><em class="property">typedef </em>int32_t <code class="descname">os_stime_t</code><a class="headerlink" href="#c.os_stime_t" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-</div>
-<div class="breathe-sectiondef docutils container">
-<p class="breathe-sectiondef-title rubric">Functions</p>
-<dl class="function">
-<dt id="c.os_time_get">
-<span class="target" id="os__time_8h_1ac20647237280640f96f61558fb7f0762"></span><a class="reference internal" href="#c.os_time_t" title="os_time_t">os_time_t</a> <code class="descname">os_time_get</code><span class="sig-paren">(</span>void<span class="sig-paren">)</span><a class="headerlink" href="#c.os_time_get" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="function">
-<dt id="c.os_time_advance">
-<span class="target" id="os__time_8h_1a1804fd98423ee3fb364cd7394de12c58"></span>void <code class="descname">os_time_advance</code><span class="sig-paren">(</span>int<em>&nbsp;ticks</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_time_advance" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="function">
-<dt id="c.os_time_delay">
-<span class="target" id="os__time_8h_1a7213d633b86da8e00d13061d12a1f075"></span>void <code class="descname">os_time_delay</code><span class="sig-paren">(</span>int32_t<em>&nbsp;osticks</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_time_delay" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="function">
-<dt id="c.os_settimeofday">
-<span class="target" id="os__time_8h_1a51fe1688dd54af6c0f8f564f4cad2f0e"></span>int <code class="descname">os_settimeofday</code><span class="sig-paren">(</span>struct  <a class="reference internal" href="#c.os_timeval" title="os_timeval">os_timeval</a>  *<em>&nbsp;utctime</em>, struct  <a class="reference internal" href="#c.os_timezone" title="os_timezone">os_timezone</a>  *<em>&nbsp;tz</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_settimeofday" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="function">
-<dt id="c.os_gettimeofday">
-<span class="target" id="os__time_8h_1ab552d38ffef88c59f99d40e6c960f10b"></span>int <code class="descname">os_gettimeofday</code><span class="sig-paren">(</span>struct  <a class="reference internal" href="#c.os_timeval" title="os_timeval">os_timeval</a>  *<em>&nbsp;utctime</em>, struct  <a class="reference internal" href="#c.os_timezone" title="os_timezone">os_timezone</a>  *<em>&nbsp;tz</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_gettimeofday" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="function">
-<dt id="c.os_get_uptime_usec">
-<span class="target" id="os__time_8h_1a68328fcd56f96d4af71ad36d6b90abe2"></span>int64_t <code class="descname">os_get_uptime_usec</code><span class="sig-paren">(</span>void<span class="sig-paren">)</span><a class="headerlink" href="#c.os_get_uptime_usec" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="function">
-<dt id="c.os_time_ms_to_ticks">
-<span class="target" id="os__time_8h_1ae5d9e53dfa7e8fd721766271ea003ac7"></span>int <code class="descname">os_time_ms_to_ticks</code><span class="sig-paren">(</span>uint32_t<em>&nbsp;ms</em>, uint32_t *<em>&nbsp;out_ticks</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_time_ms_to_ticks" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-</div>
-<dl class="struct">
-<dt id="c.os_timeval">
-<span class="target" id="structos__timeval"></span><em class="property">struct </em><code class="descname">os_timeval</code><a class="headerlink" href="#c.os_timeval" title="Permalink to this definition">?</a></dt>
-<dd><em>#include &lt;os_time.h&gt;</em><div class="breathe-sectiondef docutils container">
-<p class="breathe-sectiondef-title rubric">Public Members</p>
-<dl class="variable">
-<dt id="c.os_timeval::tv_sec">
-<span class="target" id="structos__timeval_1a6bbdf1d5b61062acecc5dcc2661a3f44"></span>int64_t <code class="descname">tv_sec</code><a class="headerlink" href="#c.os_timeval::tv_sec" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="variable">
-<dt id="c.os_timeval::tv_usec">
-<span class="target" id="structos__timeval_1a868811e9bc05070dca9a7fa4db7ec515"></span>int32_t <code class="descname">tv_usec</code><a class="headerlink" href="#c.os_timeval::tv_usec" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-</div>
-</dd></dl>
-
-<dl class="struct">
-<dt id="c.os_timezone">
-<span class="target" id="structos__timezone"></span><em class="property">struct </em><code class="descname">os_timezone</code><a class="headerlink" href="#c.os_timezone" title="Permalink to this definition">?</a></dt>
-<dd><em>#include &lt;os_time.h&gt;</em><div class="breathe-sectiondef docutils container">
-<p class="breathe-sectiondef-title rubric">Public Members</p>
-<dl class="variable">
-<dt id="c.os_timezone::tz_minuteswest">
-<span class="target" id="structos__timezone_1aa49a54e62d0e87482130d87c5eab0022"></span>int16_t <code class="descname">tz_minuteswest</code><a class="headerlink" href="#c.os_timezone::tz_minuteswest" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="variable">
-<dt id="c.os_timezone::tz_dsttime">
-<span class="target" id="structos__timezone_1a2644f6e4558f08da4d94b4dc27d6d5e5"></span>int16_t <code class="descname">tz_dsttime</code><a class="headerlink" href="#c.os_timezone::tz_dsttime" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-</div>
-</dd></dl>
-
-</div>
-<div class="section" id="task">
-<h2><a class="toc-backref" href="#id5">Task</a><a class="headerlink" href="#task" title="Permalink to this headline">?</a></h2>
-<div class="breathe-sectiondef docutils container">
-<p class="breathe-sectiondef-title rubric">Defines</p>
-<dl class="define">
-<dt id="c.OS_TASK_PRI_HIGHEST">
-<span class="target" id="os__task_8h_1a93bc03e4d136b0262c3be351546d90a3"></span><code class="descname">OS_TASK_PRI_HIGHEST</code><a class="headerlink" href="#c.OS_TASK_PRI_HIGHEST" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="define">
-<dt id="c.OS_TASK_PRI_LOWEST">
-<span class="target" id="os__task_8h_1a3b2c641ef3afd2033ab312b900634cca"></span><code class="descname">OS_TASK_PRI_LOWEST</code><a class="headerlink" href="#c.OS_TASK_PRI_LOWEST" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="define">
-<dt id="c.OS_TASK_FLAG_NO_TIMEOUT">
-<span class="target" id="os__task_8h_1a0728b4db08cbfa190ffe8748fe3430bc"></span><code class="descname">OS_TASK_FLAG_NO_TIMEOUT</code><a class="headerlink" href="#c.OS_TASK_FLAG_NO_TIMEOUT" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="define">
-<dt id="c.OS_TASK_FLAG_SEM_WAIT">
-<span class="target" id="os__task_8h_1a86f7848c389417413b98191082717d08"></span><code class="descname">OS_TASK_FLAG_SEM_WAIT</code><a class="headerlink" href="#c.OS_TASK_FLAG_SEM_WAIT" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="define">
-<dt id="c.OS_TASK_FLAG_MUTEX_WAIT">
-<span class="target" id="os__task_8h_1aab125531a2394b65d7327c5f09cff689"></span><code class="descname">OS_TASK_FLAG_MUTEX_WAIT</code><a class="headerlink" href="#c.OS_TASK_FLAG_MUTEX_WAIT" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="define">
-<dt id="c.OS_TASK_FLAG_EVQ_WAIT">
-<span class="target" id="os__task_8h_1a7886a157f2de8c02484404050fc1c7ac"></span><code class="descname">OS_TASK_FLAG_EVQ_WAIT</code><a class="headerlink" href="#c.OS_TASK_FLAG_EVQ_WAIT" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="define">
-<dt id="c.OS_TASK_MAX_NAME_LEN">
-<span class="target" id="os__task_8h_1ab9a4544def04dd6cfbaf93cd51785452"></span><code class="descname">OS_TASK_MAX_NAME_LEN</code><a class="headerlink" href="#c.OS_TASK_MAX_NAME_LEN" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-</div>
-<div class="breathe-sectiondef docutils container">
-<p class="breathe-sectiondef-title rubric">Typedefs</p>
-<dl class="typedef">
-<dt id="c.os_task_state_t">
-<span class="target" id="os__task_8h_1a106cd7d63dabd9800363a0c9b5ff40d1"></span><em class="property">typedef </em>enum <a class="reference internal" href="#c.os_task_state" title="os_task_state">os_task_state</a>  <code class="descname">os_task_state_t</code><a class="headerlink" href="#c.os_task_state_t" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="typedef">
-<dt id="c.os_task_func_t">
-<span class="target" id="os__task_8h_1a831f9a3ebc7c5e7b4aac94d581eba82c"></span><em class="property">typedef </em>void<code class="descname">(* os_task_func_t)</code><span class="sig-paren">(</span>void<em>&nbsp;*</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_task_func_t" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-</div>
-<div class="breathe-sectiondef docutils container">
-<p class="breathe-sectiondef-title rubric">Enums</p>
-<dl class="enum">
-<dt id="c.os_task_state">
-<span class="target" id="os__task_8h_1a897c47c6381207ebaea3963c43362f88"></span><em class="property">enum </em><code class="descname">os_task_state</code><a class="headerlink" href="#c.os_task_state" title="Permalink to this definition">?</a></dt>
-<dd><p><em>Values:</em></p>
-<dl class="enumvalue">
-<dt id="c.OS_TASK_READY">
-<span class="target" id="os__task_8h_1a897c47c6381207ebaea3963c43362f88a529cd0e1f131f501efe7cc3d1122d002"></span><code class="descname">OS_TASK_READY</code> = 1<a class="headerlink" href="#c.OS_TASK_READY" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="enumvalue">
-<dt id="c.OS_TASK_SLEEP">
-<span class="target" id="os__task_8h_1a897c47c6381207ebaea3963c43362f88af7cdfa32e836ac0ef16f761a00dd6104"></span><code class="descname">OS_TASK_SLEEP</code> = 2<a class="headerlink" href="#c.OS_TASK_SLEEP" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-</dd></dl>
-
-</div>
-<div class="breathe-sectiondef docutils container">
-<p class="breathe-sectiondef-title rubric">Functions</p>
-<dl class="function">
-<dt id="c.STAILQ_HEAD">
-<span class="target" id="os__task_8h_1a7d5b7bddad6f55d7db64139daff086b8"></span><code class="descname">STAILQ_HEAD</code><span class="sig-paren">(</span>os_task_stailq, <a class="reference internal" href="#c.os_task" title="os_task">os_task</a><span class="sig-paren">)</span><a class="headerlink" href="#c.STAILQ_HEAD" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="function">
-<dt id="c.os_task_init">
-<span class="target" id="os__task_8h_1ac0604d800ed8dbfd18835cd5076a6393"></span>int <code class="descname">os_task_init</code><span class="sig-paren">(</span>struct  <a class="reference internal" href="#c.os_task" title="os_task">os_task</a> <em>&nbsp;*</em>, const char<em>&nbsp;*</em>, <a class="reference internal" href="#c.os_task_func_t" title="os_task_func_t">os_task_func_t</a>, void<em>&nbsp;*</em>, uint8_t, <a class="reference internal" href="#c.os_time_t" title="os_time_t">os_time_t</a>, os_stack_t <em>&nbsp;*</em>, uint16_t<span class="sig-paren">)</span><a class="headerlink" href="#c.os_task_init" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="function">
-<dt id="c.os_task_remove">
-<span class="target" id="os__task_8h_1acf6cfe441ddecead6a2e010165384cb4"></span>int <code class="descname">os_task_remove</code><span class="sig-paren">(</span>struct  <a class="reference internal" href="#c.os_task" title="os_task">os_task</a>  *<em>&nbsp;t</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_task_remove" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="function">
-<dt id="c.os_task_count">
-<span class="target" id="os__task_8h_1a6b14a4fbff91ab3e9fd4b9933423a590"></span>uint8_t <code class="descname">os_task_count</code><span class="sig-paren">(</span>void<span class="sig-paren">)</span><a class="headerlink" href="#c.os_task_count" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="function">
-<dt id="c.os_task_info_get_next">
-<span class="target" id="os__task_8h_1ac459b82ad909a99ff1ef0ec3cedc31d2"></span>struct <a class="reference internal" href="#c.os_task" title="os_task">os_task</a>* <code class="descname">os_task_info_get_next</code><span class="sig-paren">(</span>const struct  <a class="reference internal" href="#c.os_task" title="os_task">os_task</a> <em>&nbsp;*</em>, struct  <a class="reference internal" href="#c.os_task_info" title="os_task_info">os_task_info</a> <em>&nbsp;*</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_task_info_get_next" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-</div>
-<div class="breathe-sectiondef docutils container">
-<p class="breathe-sectiondef-title rubric">Variables</p>
-<dl class="variable">
-<dt id="c.g_os_task_list">
-<span class="target" id="os__task_8h_1ab6099632c7c9c77d3f906d1984124b1b"></span>struct os_task_stailq <code class="descname">g_os_task_list</code><a class="headerlink" href="#c.g_os_task_list" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-</div>
-<dl class="struct">
-<dt id="c.os_task_obj">
-<span class="target" id="structos__task__obj"></span><em class="property">struct </em><code class="descname">os_task_obj</code><a class="headerlink" href="#c.os_task_obj" title="Permalink to this definition">?</a></dt>
-<dd><em>#include &lt;os_task.h&gt;</em><div class="breathe-sectiondef docutils container">
-<p class="breathe-sectiondef-title rubric">Public Functions</p>
-<dl class="function">
-<dt id="c.os_task_obj::SLIST_HEAD">
-<span class="target" id="structos__task__obj_1afaaecbfac7330adf348cb0859d19ee16"></span><code class="descname">SLIST_HEAD</code><span class="sig-paren">(</span><a class="reference internal" href="#c.os_task" title="os_task">os_task</a><span class="sig-paren">)</span><a class="headerlink" href="#c.os_task_obj::SLIST_HEAD" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-</div>
-</dd></dl>
-
-<dl class="struct">
-<dt id="c.os_task">
-<span class="target" id="structos__task"></span><em class="property">struct </em><code class="descname">os_task</code><a class="headerlink" href="#c.os_task" title="Permalink to this definition">?</a></dt>
-<dd><em>#include &lt;os_task.h&gt;</em><div class="breathe-sectiondef docutils container">
-<p class="breathe-sectiondef-title rubric">Public Functions</p>
-<dl class="function">
-<dt id="c.os_task::STAILQ_ENTRY">
-<span class="target" id="structos__task_1a279206e682999706ad40bc6904172a3c"></span><code class="descname">STAILQ_ENTRY</code><span class="sig-paren">(</span><a class="reference internal" href="#c.os_task" title="os_task">os_task</a><span class="sig-paren">)</span><a class="headerlink" href="#c.os_task::STAILQ_ENTRY" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="function">
-<dt id="c.os_task::TAILQ_ENTRY">
-<span class="target" id="structos__task_1add1f53550b8a6b88dcc1e527f1cf23d3"></span><code class="descname">TAILQ_ENTRY</code><span class="sig-paren">(</span><a class="reference internal" href="#c.os_task" title="os_task">os_task</a><span class="sig-paren">)</span><a class="headerlink" href="#c.os_task::TAILQ_ENTRY" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="function">
-<dt id="c.os_task::SLIST_ENTRY">
-<span class="target" id="structos__task_1abb61293d9c80cf727bf3c6210ee4235e"></span><code class="descname">SLIST_ENTRY</code><span class="sig-paren">(</span><a class="reference internal" href="#c.os_task" title="os_task">os_task</a><span class="sig-paren">)</span><a class="headerlink" href="#c.os_task::SLIST_ENTRY" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-</div>
-<div class="breathe-sectiondef docutils container">
-<p class="breathe-sectiondef-title rubric">Public Members</p>
-<dl class="variable">
-<dt id="c.os_task::t_stackptr">
-<span class="target" id="structos__task_1afe949cfd7c42a5cb31bf8755b26ce01e"></span>os_stack_t* <code class="descname">t_stackptr</code><a class="headerlink" href="#c.os_task::t_stackptr" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="variable">
-<dt id="c.os_task::t_stacktop">
-<span class="target" id="structos__task_1a40c3ba56a847758812bc417949724588"></span>os_stack_t* <code class="descname">t_stacktop</code><a class="headerlink" href="#c.os_task::t_stacktop" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="variable">
-<dt id="c.os_task::t_stacksize">
-<span class="target" id="structos__task_1a732f272fc82004d997f87a9a906729d0"></span>uint16_t <code class="descname">t_stacksize</code><a class="headerlink" href="#c.os_task::t_stacksize" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="variable">
-<dt id="c.os_task::t_taskid">
-<span class="target" id="structos__task_1a9fbae9501044635c01be92ac56d01b4c"></span>uint8_t <code class="descname">t_taskid</code><a class="headerlink" href="#c.os_task::t_taskid" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="variable">
-<dt id="c.os_task::t_prio">
-<span class="target" id="structos__task_1a412fe15c516151b1864e3e77b4d79199"></span>uint8_t <code class="descname">t_prio</code><a class="headerlink" href="#c.os_task::t_prio" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="variable">
-<dt id="c.os_task::t_state">
-<span class="target" id="structos__task_1a9af24b262fca10170d561e875f504ea9"></span>uint8_t <code class="descname">t_state</code><a class="headerlink" href="#c.os_task::t_state" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="variable">
-<dt id="c.os_task::t_flags">
-<span class="target" id="structos__task_1af58aa554823b3ae3655b6672d2bf93ca"></span>uint8_t <code class="descname">t_flags</code><a class="headerlink" href="#c.os_task::t_flags" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="variable">
-<dt id="c.os_task::t_lockcnt">
-<span class="target" id="structos__task_1a608d3c25c23da998c492836295782a0b"></span>uint8_t <code class="descname">t_lockcnt</code><a class="headerlink" href="#c.os_task::t_lockcnt" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="variable">
-<dt id="c.os_task::t_pad">
-<span class="target" id="structos__task_1a52a1cd41ec2209b3b51e71c41fbb051f"></span>uint8_t <code class="descname">t_pad</code><a class="headerlink" href="#c.os_task::t_pad" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="variable">
-<dt id="c.os_task::t_name">
-<span class="target" id="structos__task_1a617c03d12fe7051db4c6b032f4c764a8"></span>const char* <code class="descname">t_name</code><a class="headerlink" href="#c.os_task::t_name" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="variable">
-<dt id="c.os_task::t_func">
-<span class="target" id="structos__task_1a2a2d6ea1f625cd6a90c6e6f6a5aba160"></span><a class="reference internal" href="#c.os_task_func_t" title="os_task_func_t">os_task_func_t</a> <code class="descname">t_func</code><a class="headerlink" href="#c.os_task::t_func" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="variable">
-<dt id="c.os_task::t_arg">
-<span class="target" id="structos__task_1a39b3109b30ba2c821cad2cca3dd77fec"></span>void* <code class="descname">t_arg</code><a class="headerlink" href="#c.os_task::t_arg" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="variable">
-<dt id="c.os_task::t_obj">
-<span class="target" id="structos__task_1aa23d60f19ae3e48f859b40cafd83f1ae"></span>void* <code class="descname">t_obj</code><a class="headerlink" href="#c.os_task::t_obj" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="variable">
-<dt id="c.os_task::t_sanity_check">
-<span class="target" id="structos__task_1a24958d799042b17927b0f94405f193cf"></span>struct os_sanity_check <code class="descname">t_sanity_check</code><a class="headerlink" href="#c.os_task::t_sanity_check" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="variable">
-<dt id="c.os_task::t_next_wakeup">
-<span class="target" id="structos__task_1adc9eebeea4dd7cb212de3ee04b113a71"></span><a class="reference internal" href="#c.os_time_t" title="os_time_t">os_time_t</a> <code class="descname">t_next_wakeup</code><a class="headerlink" href="#c.os_task::t_next_wakeup" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="variable">
-<dt id="c.os_task::t_run_time">
-<span class="target" id="structos__task_1a980815aadda46b23373395854907ef0b"></span><a class="reference internal" href="#c.os_time_t" title="os_time_t">os_time_t</a> <code class="descname">t_run_time</code><a class="headerlink" href="#c.os_task::t_run_time" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="variable">
-<dt id="c.os_task::t_ctx_sw_cnt">
-<span class="target" id="structos__task_1a0c51f9ebf2d06ec8e3f5bddd860606e1"></span>uint32_t <code class="descname">t_ctx_sw_cnt</code><a class="headerlink" href="#c.os_task::t_ctx_sw_cnt" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-</div>
-</dd></dl>
-
-<dl class="struct">
-<dt id="c.os_task_info">
-<span class="target" id="structos__task__info"></span><em class="property">struct </em><code class="descname">os_task_info</code><a class="headerlink" href="#c.os_task_info" title="Permalink to this definition">?</a></dt>
-<dd><em>#include &lt;os_task.h&gt;</em><div class="breathe-sectiondef docutils container">
-<p class="breathe-sectiondef-title rubric">Public Members</p>
-<dl class="variable">
-<dt id="c.os_task_info::oti_prio">
-<span class="target" id="structos__task__info_1a3b9e108c245f706c1f238639e1fcc411"></span>uint8_t <code class="descname">oti_prio</code><a class="headerlink" href="#c.os_task_info::oti_prio" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="variable">
-<dt id="c.os_task_info::oti_taskid">
-<span class="target" id="structos__task__info_1acfc3100a590d117396ba39bdc14c9fe1"></span>uint8_t <code class="descname">oti_taskid</code><a class="headerlink" href="#c.os_task_info::oti_taskid" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="variable">
-<dt id="c.os_task_info::oti_state">
-<span class="target" id="structos__task__info_1a887a2fae644c0d174423ce1724f91a0e"></span>uint8_t <code class="descname">oti_state</code><a class="headerlink" href="#c.os_task_info::oti_state" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="variable">
-<dt id="c.os_task_info::oti_stkusage">
-<span class="target" id="structos__task__info_1af660e42807b73fac357753873f89baf0"></span>uint16_t <code class="descname">oti_stkusage</code><a class="headerlink" href="#c.os_task_info::oti_stkusage" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="variable">
-<dt id="c.os_task_info::oti_stksize">
-<span class="target" id="structos__task__info_1ac306d37cb458c796e7bd876ce3724acc"></span>uint16_t <code class="descname">oti_stksize</code><a class="headerlink" href="#c.os_task_info::oti_stksize" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="variable">
-<dt id="c.os_task_info::oti_cswcnt">
-<span class="target" id="structos__task__info_1a9acbf3e6b3a274ab40951ef54c75ab38"></span>uint32_t <code class="descname">oti_cswcnt</code><a class="headerlink" href="#c.os_task_info::oti_cswcnt" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="variable">
-<dt id="c.os_task_info::oti_runtime">
-<span class="target" id="structos__task__info_1aeefcf9aeb3aaad24f401d56089842dd8"></span>uint32_t <code class="descname">oti_runtime</code><a class="headerlink" href="#c.os_task_info::oti_runtime" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="variable">
-<dt id="c.os_task_info::oti_last_checkin">
-<span class="target" id="structos__task__info_1a7b5a7274c1237db848cdc04e97f6a715"></span><a class="reference internal" href="#c.os_time_t" title="os_time_t">os_time_t</a> <code class="descname">oti_last_checkin</code><a class="headerlink" href="#c.os_task_info::oti_last_checkin" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="variable">
-<dt id="c.os_task_info::oti_next_checkin">
-<span class="target" id="structos__task__info_1a5f851a446f55aa79f258cab528d10dfe"></span><a class="reference internal" href="#c.os_time_t" title="os_time_t">os_time_t</a> <code class="descname">oti_next_checkin</code><a class="headerlink" href="#c.os_task_info::oti_next_checkin" title="Permalink to this definition">?</a></dt>
-<dd></dd></dl>
-
-<dl class="variable">
-<dt>
-<span class="target" id="structos__task__info_1a100f609783651bcbd369982613570f72"></span><code class="descname">char os_task_info::oti_name[OS_TASK_MAX_NAME_LEN]</code></dt>
-<dd></dd></dl>
-
-</div>
-</dd></dl>
-
-</div>
-</div>
-
-
-                   </div>
-                  </div>
-                  
-    <div class="rst-footer-buttons row" role="navigation" aria-label="footer navigation">
-      
-        <a href="porting/port_os.html" class="btn btn-neutral float-right" title="Porting Mynewt OS" accesskey="n">Next: Porting Mynewt OS <span class="fa fa-arrow-circle-right"></span></a>
-      
-      
-        <a href="callout/callout.html" class="btn btn-neutral" title="Callout" accesskey="p"><span class="fa fa-arrow-circle-left"></span> Previous: Callout</a>
-      
-    </div>
-
-                </div>
-              </div>
-            </div>
-            <!-- ENDS CONTENT SECTION -->
-          </div>
-          <!-- ENDS .content -->
-        </div>
-      </div>
-      <footer>
-  <div class="container">
-    <div class="row">
-      <div class="col-xs-12">
-          
-              <p class="copyright">Apache Mynewt is available under Apache License, version 2.0.</p>
-          
-      </div>
-      <div class="col-xs-12">
-          <div class="logos">
-              <img src="../../_static/img/asf_logo_wide_small.png" alt="Apache" title="Apache">
-              <small class="footnote">
-                Apache Mynewt, Mynewt, Apache, the Apache feather logo, and the Apache Mynewt project logo are either
-                registered trademarks or trademarks of the Apache Software Foundation in the United States and other countries.
-              </small>
-              <a href="https://join.slack.com/mynewt/shared_invite/MTkwMTg1ODM1NTg5LTE0OTYxNzQ4NzQtZTU1YmNhYjhkMg">
-                <img src="../../_static/img/add_to_slack.png" alt="Slack Icon" title="Join our Slack Community" />
-              </a>
-          </div>
-      </div>
-    </div>
-  </div>
-</footer>
-    </div>
-    <!-- ENDS #wrapper -->
-
-  
-
-    <script type="text/javascript">
-        var DOCUMENTATION_OPTIONS = {
-            URL_ROOT:'../../',
-            VERSION:'1.3.0',
-            COLLAPSE_INDEX:false,
-            FILE_SUFFIX:'.html',
-            HAS_SOURCE:  true,
-            SOURCELINK_SUFFIX: '.txt'
-        };
-    </script>
-      <script type="text/javascript" src="../../_static/jquery.js"></script>
-      <script type="text/javascript" src="../../_static/underscore.js"></script>
-      <script type="text/javascript" src="../../_static/doctools.js"></script>
-      <script type="text/javascript" src="../../_static/js/bootstrap-3.0.3.min.js"></script>
-      <script type="text/javascript" src="../../_static/js/affix.js"></script>
-      <script type="text/javascript" src="../../_static/js/main.js"></script>
-
-   
-
-  </body>
-</html>
\ No newline at end of file
diff --git a/develop/os/core_os/callout/callout.html b/develop/os/core_os/callout/callout.html
index de17b0489..a85263959 100644
--- a/develop/os/core_os/callout/callout.html
+++ b/develop/os/core_os/callout/callout.html
@@ -41,9 +41,9 @@
                 href="../../../genindex.html"/>
           <link rel="search" title="Search" href="../../../search.html"/>
       <link rel="top" title="Apache Mynewt 1.3.0 documentation" href="../../../index.html"/>
-          <link rel="up" title="Mynewt Core OS" href="../mynewt_os.html"/>
-          <link rel="next" title="Core OS API" href="../API.html"/>
-          <link rel="prev" title="Sanity" href="../sanity/sanity.html"/> 
+          <link rel="up" title="Apache Mynewt Operating System Kernel" href="../mynewt_os.html"/>
+          <link rel="next" title="Heap" href="../heap/heap.html"/>
+          <link rel="prev" title="Event Queues" href="../event_queue/event_queue.html"/> 
 
     
     <script src="../../../_static/js/modernizr.min.js"></script>
@@ -156,7 +156,7 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
     
       <a href="../../os_user_guide.html">OS User Guide</a> /
     
-      <a href="../mynewt_os.html">Mynewt Core OS</a> /
+      <a href="../mynewt_os.html">Apache Mynewt Operating System Kernel</a> /
     
     Callout
     
@@ -224,27 +224,25 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
 <li class="toctree-l1"><a class="reference internal" href="../../../concepts.html">Concepts</a></li>
 <li class="toctree-l1"><a class="reference internal" href="../../../tutorials/tutorials.html">Tutorials</a></li>
 <li class="toctree-l1 current"><a class="reference internal" href="../../os_user_guide.html">OS User Guide</a><ul class="current">
-<li class="toctree-l2 current"><a class="reference internal" href="../mynewt_os.html">OS Core</a><ul class="current">
+<li class="toctree-l2 current"><a class="reference internal" href="../mynewt_os.html">Kernel</a><ul class="current">
 <li class="toctree-l3"><a class="reference internal" href="../context_switch/context_switch.html">Scheduler</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../cputime/os_cputime.html">CPU Time</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../time/os_time.html">OS Time</a></li>
 <li class="toctree-l3"><a class="reference internal" href="../task/task.html">Task</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../event_queue/event_queue.html">Event Queues</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../semaphore/semaphore.html">Semaphore</a></li>
 <li class="toctree-l3"><a class="reference internal" href="../mutex/mutex.html">Mutex</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../memory_pool/memory_pool.html">Memory Pools</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../semaphore/semaphore.html">Semaphore</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../event_queue/event_queue.html">Event Queues</a></li>
+<li class="toctree-l3 current"><a class="current reference internal" href="#">Callout</a></li>
 <li class="toctree-l3"><a class="reference internal" href="../heap/heap.html">Heap</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../memory_pool/memory_pool.html">Memory Pools</a></li>
 <li class="toctree-l3"><a class="reference internal" href="../mbuf/mbuf.html">Mbufs</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../msys/msys.html">Msys</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../mqueue/mqueue.html">Mqueue</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../cputime/os_cputime.html">CPU Time</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../time/os_time.html">OS Time</a></li>
 <li class="toctree-l3"><a class="reference internal" href="../sanity/sanity.html">Sanity</a></li>
-<li class="toctree-l3 current"><a class="current reference internal" href="#">Callout</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../API.html">API</a></li>
 </ul>
 </li>
-<li class="toctree-l2"><a class="reference internal" href="../porting/port_os.html">Porting Mynewt OS</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../../modules/hal/hal.html">Hardware Abstraction</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../porting/port_os.html">Porting Guide</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../../modules/sysinitconfig/sysinitconfig.html">System Configuration</a></li>
 <li class="toctree-l2"><a class="reference internal" href="../../modules/console/console.html">Console</a></li>
-<li class="toctree-l2"><a class="reference internal" href="../../modules/sysinitconfig/sysinitconfig.html">System Configuration and Initialization</a></li>
 </ul>
 </li>
 <li class="toctree-l1"><a class="reference internal" href="../../../network/ble/ble_intro.html">BLE User Guide</a></li>
@@ -280,100 +278,133 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
                     
   <div class="section" id="callout">
 <h1>Callout<a class="headerlink" href="#callout" title="Permalink to this headline">?</a></h1>
-<p>Callouts are MyNewt OS timers.</p>
+<p>Callouts are Apache Mynewt OS timers.</p>
 <div class="section" id="description">
 <h2>Description<a class="headerlink" href="#description" title="Permalink to this headline">?</a></h2>
 <p>Callout is a way of setting up an OS timer. When the timer fires, it is
 delivered as an event to task?s event queue.</p>
 <p>User would initialize their callout structure using
-<em>os_callout_init()</em>, or <em>os_callout_func_init()</em> and then arm it
-with <em>os_callout_reset()</em>.</p>
+<a class="reference internal" href="#c.os_callout_init" title="os_callout_init"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_callout_init()</span></code></a>, or <code class="xref c c-func docutils literal notranslate"><span class="pre">os_callout_func_init()</span></code> and
+then arm it with <a class="reference internal" href="#c.os_callout_reset" title="os_callout_reset"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_callout_reset()</span></code></a>.</p>
 <p>If user wants to cancel the timer before it expires, they can either use
-<em>os_callout_reset()</em> to arm it for later expiry, or stop it altogether
-by calling <em>os_callout_stop()</em>.</p>
+<a class="reference internal" href="#c.os_callout_reset" title="os_callout_reset"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_callout_reset()</span></code></a> to arm it for later expiry, or stop it altogether
+by calling <a class="reference internal" href="#c.os_callout_stop" title="os_callout_stop"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_callout_stop()</span></code></a>.</p>
 <p>There are 2 different options for data structure to use. First is
-<em>struct os_callout</em>, which is a bare-bones version. You would
-initialize this with <em>os_callout_init()</em>.</p>
-<p>Second option is <em>struct os_callout_func</em>. This you can use if you
+<code class="xref c c-type docutils literal notranslate"><span class="pre">struct</span> <span class="pre">os_callout</span></code>, which is a bare-bones version. You would
+initialize this with <a class="reference internal" href="#c.os_callout_init" title="os_callout_init"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_callout_init()</span></code></a>.</p>
+<p>Second option is <code class="xref c c-type docutils literal notranslate"><span class="pre">struct</span> <span class="pre">os_callout_func</span></code>. This you can use if you
 expect to have multiple different types of timers in your task, running
 concurrently. The structure contains a function pointer, and you would
 call that function from your task?s event processing loop.</p>
 <p>Time unit when arming the timer is OS ticks. This rate of this ticker
 depends on the platform this is running on. You should use OS define
-<em>OS_TICKS_PER_SEC</em> to convert wallclock time to OS ticks.</p>
+<code class="docutils literal notranslate"><span class="pre">OS_TICKS_PER_SEC</span></code> to convert wallclock time to OS ticks.</p>
 <p>Callout timer fires out just once. For periodic timer type of operation
 you need to rearm it once it fires.</p>
-</div>
-<div class="section" id="data-structures">
-<h2>Data structures<a class="headerlink" href="#data-structures" title="Permalink to this headline">?</a></h2>
-<div class="highlight-none notranslate"><div class="highlight"><pre><span></span>struct os_callout {
-    struct os_event c_ev;
-    struct os_eventq *c_evq;
-    uint32_t c_ticks;
-    TAILQ_ENTRY(os_callout) c_next;
-};
-</pre></div>
-</div>
-<table border="1" class="docutils">
-<colgroup>
-<col width="17%" />
-<col width="83%" />
-</colgroup>
-<thead valign="bottom">
-<tr class="row-odd"><th class="head">Element</th>
-<th class="head">Description</th>
-</tr>
-</thead>
-<tbody valign="top">
-<tr class="row-even"><td>c_ev</td>
-<td>Event structure of this callout</td>
-</tr>
-<tr class="row-odd"><td>c_evq</td>
-<td>Event queue where this callout is placed on timer expiry</td>
-</tr>
-<tr class="row-even"><td>c_ticks</td>
-<td>OS tick amount when timer fires</td>
-</tr>
-<tr class="row-odd"><td>c_next</td>
-<td>Linkage to other unexpired callouts</td>
-</tr>
-</tbody>
-</table>
-<div class="highlight-none notranslate"><div class="highlight"><pre><span></span>struct os_callout_func {
-    struct os_callout cf_c;
-    os_callout_func_t cf_func;
-    void *cf_arg;
-};
-</pre></div>
-</div>
-<table border="1" class="docutils">
-<colgroup>
-<col width="15%" />
-<col width="85%" />
-</colgroup>
-<thead valign="bottom">
-<tr class="row-odd"><th class="head">Element</th>
-<th class="head">Description</th>
-</tr>
-</thead>
-<tbody valign="top">
-<tr class="row-even"><td>cf_c</td>
-<td>struct os_callout. See above</td>
-</tr>
-<tr class="row-odd"><td>cf_func</td>
-<td>Function pointer which should be called by event queue processing</td>
-</tr>
-<tr class="row-even"><td>cf_arg</td>
-<td>Generic void * argument to that function</td>
-</tr>
-</tbody>
-</table>
 <div class="section" id="api">
 <h3>API<a class="headerlink" href="#api" title="Permalink to this headline">?</a></h3>
-<div class="admonition warning">
-<p class="first admonition-title">Warning</p>
-<p class="last">doxygengroup: Cannot find namespace ?OSCallouts? in doxygen xml output for project ?mynewt-core? from directory: mynewt-core-xml</p>
+<dl class="function">
+<dt id="c.os_callout_init">
+<span class="target" id="group___o_s_callouts_1gac1a34a023c7a9eb52e46c5155855debd"></span>void <code class="descname">os_callout_init</code><span class="sig-paren">(</span>struct  os_callout  *<em>&nbsp;cf</em>, struct  os_eventq  *<em>&nbsp;evq</em>, <a class="reference internal" href="../event_queue/event_queue.html#c.os_event_fn" title="os_event_fn">os_event_fn</a>  *<em>&nbsp;ev_cb</em>, void *<em>&nbsp;ev_arg</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_callout_init" title="Permalink to this definition">?</a></dt>
+<dd><p>Initialize a callout. </p>
+<p>Callouts are used to schedule events in the future onto a task?s event queue. Callout timers are scheduled using the <a class="reference internal" href="#group___o_s_callouts_1ga4de794bb3092ac43628371d9d376c61b"><span class="std std-ref">os_callout_reset()</span></a> function. When the timer expires, an event is posted to the event queue specified in <a class="reference internal" href="#group___o_s_callouts_1gac1a34a023c7a9eb52e46c5155855debd"><span class="std std-ref">os_callout_init()</span></a>. The event argument given here is posted in the ev_arg field of that event.</p>
+<p><dl class="docutils">
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">c</span></code>: The callout to initialize </li>
+<li><code class="docutils literal notranslate"><span class="pre">evq</span></code>: The event queue to post an OS_EVENT_T_TIMER event to </li>
+<li><code class="docutils literal notranslate"><span class="pre">timo_func</span></code>: The function to call on this callout for the host task used to provide multiple timer events to a task (this can be NULL.) </li>
+<li><code class="docutils literal notranslate"><span class="pre">ev_arg</span></code>: The argument to provide to the event when posting the timer. </li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_callout_stop">
+<span class="target" id="group___o_s_callouts_1ga661bbf1a84775044ac93d9464688e4bb"></span>void <code class="descname">os_callout_stop</code><span class="sig-paren">(</span>struct  os_callout <em>&nbsp;*</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_callout_stop" title="Permalink to this definition">?</a></dt>
+<dd><p>Stop the callout from firing off, any pending events will be cleared. </p>
+<p><dl class="docutils">
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">c</span></code>: The callout to stop </li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_callout_reset">
+<span class="target" id="group___o_s_callouts_1ga4de794bb3092ac43628371d9d376c61b"></span>int <code class="descname">os_callout_reset</code><span class="sig-paren">(</span>struct  os_callout <em>&nbsp;*</em>, int32_t<span class="sig-paren">)</span><a class="headerlink" href="#c.os_callout_reset" title="Permalink to this definition">?</a></dt>
+<dd><p>Reset the callout to fire off in ?ticks? ticks. </p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>0 on success, non-zero on failure </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">c</span></code>: The callout to reset </li>
+<li><code class="docutils literal notranslate"><span class="pre">ticks</span></code>: The number of ticks to wait before posting an event</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_callout_remaining_ticks">
+<span class="target" id="group___o_s_callouts_1gab0809de1868462fe0a066f67645342be"></span><a class="reference internal" href="../time/os_time.html#c.os_time_t" title="os_time_t">os_time_t</a> <code class="descname">os_callout_remaining_ticks</code><span class="sig-paren">(</span>struct  os_callout <em>&nbsp;*</em>, <a class="reference internal" href="../time/os_time.html#c.os_time_t" title="os_time_t">os_time_t</a><span class="sig-paren">)</span><a class="headerlink" href="#c.os_callout_remaining_ticks" title="Permalink to this definition">?</a></dt>
+<dd></dd></dl>
+
+<dl class="function">
+<dt id="c.os_callout_queued">
+<span class="target" id="group___o_s_callouts_1ga9f0d8c6cb4cd1a10a269fe004cf12e45"></span>static int <code class="descname">os_callout_queued</code><span class="sig-paren">(</span>struct  os_callout  *<em>&nbsp;c</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_callout_queued" title="Permalink to this definition">?</a></dt>
+<dd><p>Returned whether or not the callout has been posted to it?s event queue. </p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>1 if queued, 0 if not queued. </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">c</span></code>: The callout to check</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="define">
+<dt id="c.OS_CALLOUT_F_QUEUED">
+<span class="target" id="group___o_s_callouts_1gaec2251c9ec00bece85a077edfa703063"></span><code class="descname">OS_CALLOUT_F_QUEUED</code><a class="headerlink" href="#c.OS_CALLOUT_F_QUEUED" title="Permalink to this definition">?</a></dt>
+<dd></dd></dl>
+
+<dl class="class">
+<dt id="_CPPv310os_callout">
+<span id="_CPPv210os_callout"></span><span id="os_callout"></span><span class="target" id="structos__callout"></span><em class="property">struct </em><code class="descname">os_callout</code><a class="headerlink" href="#_CPPv310os_callout" title="Permalink to this definition">?</a><br /></dt>
+<dd><em>#include &lt;os_callout.h&gt;</em><p>Structure containing the definition of a callout, initialized by <a class="reference internal" href="#group___o_s_callouts_1gac1a34a023c7a9eb52e46c5155855debd"><span class="std std-ref">os_callout_init()</span></a> and passed to callout functions. </p>
+<div class="breathe-sectiondef docutils container">
+<p class="breathe-sectiondef-title rubric">Public Members</p>
+<dl class="variable">
+<dt id="c.os_callout::c_ev">
+<span class="target" id="structos__callout_1a6e3cac590085fde37bdc3efac687cedf"></span>struct os_event <code class="descname">c_ev</code><a class="headerlink" href="#c.os_callout::c_ev" title="Permalink to this definition">?</a></dt>
+<dd><p>Event to post when the callout expires. </p>
+</dd></dl>
+
+<dl class="variable">
+<dt id="c.os_callout::c_evq">
+<span class="target" id="structos__callout_1a81692681ef25523c32e893cd66b612a2"></span>struct os_eventq* <code class="descname">c_evq</code><a class="headerlink" href="#c.os_callout::c_evq" title="Permalink to this definition">?</a></dt>
+<dd><p>Pointer to the event queue to post the event to. </p>
+</dd></dl>
+
+<dl class="variable">
+<dt id="c.os_callout::c_ticks">
+<span class="target" id="structos__callout_1a494eb97a37291c4f86d973cbb73489d5"></span>uint32_t <code class="descname">c_ticks</code><a class="headerlink" href="#c.os_callout::c_ticks" title="Permalink to this definition">?</a></dt>
+<dd><p>Number of ticks in the future to expire the callout. </p>
+</dd></dl>
+
 </div>
+</dd></dl>
+
 </div>
 </div>
 </div>
@@ -384,10 +415,10 @@ <h3>API<a class="headerlink" href="#api" title="Permalink to this headline">?</
                   
     <div class="rst-footer-buttons row" role="navigation" aria-label="footer navigation">
       
-        <a href="../API.html" class="btn btn-neutral float-right" title="Core OS API" accesskey="n">Next: Core OS API <span class="fa fa-arrow-circle-right"></span></a>
+        <a href="../heap/heap.html" class="btn btn-neutral float-right" title="Heap" accesskey="n">Next: Heap <span class="fa fa-arrow-circle-right"></span></a>
       
       
-        <a href="../sanity/sanity.html" class="btn btn-neutral" title="Sanity" accesskey="p"><span class="fa fa-arrow-circle-left"></span> Previous: Sanity</a>
+        <a href="../event_queue/event_queue.html" class="btn btn-neutral" title="Event Queues" accesskey="p"><span class="fa fa-arrow-circle-left"></span> Previous: Event Queues</a>
       
     </div>
 
diff --git a/develop/os/core_os/context_switch/context_switch.html b/develop/os/core_os/context_switch/context_switch.html
index 8c4b0035f..6a6e2a1e4 100644
--- a/develop/os/core_os/context_switch/context_switch.html
+++ b/develop/os/core_os/context_switch/context_switch.html
@@ -41,9 +41,9 @@
                 href="../../../genindex.html"/>
           <link rel="search" title="Search" href="../../../search.html"/>
       <link rel="top" title="Apache Mynewt 1.3.0 documentation" href="../../../index.html"/>
-          <link rel="up" title="Mynewt Core OS" href="../mynewt_os.html"/>
-          <link rel="next" title="CPU Time" href="../cputime/os_cputime.html"/>
-          <link rel="prev" title="Mynewt Core OS" href="../mynewt_os.html"/> 
+          <link rel="up" title="Apache Mynewt Operating System Kernel" href="../mynewt_os.html"/>
+          <link rel="next" title="Task" href="../task/task.html"/>
+          <link rel="prev" title="Apache Mynewt Operating System Kernel" href="../mynewt_os.html"/> 
 
     
     <script src="../../../_static/js/modernizr.min.js"></script>
@@ -156,7 +156,7 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
     
       <a href="../../os_user_guide.html">OS User Guide</a> /
     
-      <a href="../mynewt_os.html">Mynewt Core OS</a> /
+      <a href="../mynewt_os.html">Apache Mynewt Operating System Kernel</a> /
     
     Scheduler
     
@@ -224,27 +224,25 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
 <li class="toctree-l1"><a class="reference internal" href="../../../concepts.html">Concepts</a></li>
 <li class="toctree-l1"><a class="reference internal" href="../../../tutorials/tutorials.html">Tutorials</a></li>
 <li class="toctree-l1 current"><a class="reference internal" href="../../os_user_guide.html">OS User Guide</a><ul class="current">
-<li class="toctree-l2 current"><a class="reference internal" href="../mynewt_os.html">OS Core</a><ul class="current">
+<li class="toctree-l2 current"><a class="reference internal" href="../mynewt_os.html">Kernel</a><ul class="current">
 <li class="toctree-l3 current"><a class="current reference internal" href="#">Scheduler</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../cputime/os_cputime.html">CPU Time</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../time/os_time.html">OS Time</a></li>
 <li class="toctree-l3"><a class="reference internal" href="../task/task.html">Task</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../event_queue/event_queue.html">Event Queues</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../semaphore/semaphore.html">Semaphore</a></li>
 <li class="toctree-l3"><a class="reference internal" href="../mutex/mutex.html">Mutex</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../memory_pool/memory_pool.html">Memory Pools</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../semaphore/semaphore.html">Semaphore</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../event_queue/event_queue.html">Event Queues</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../callout/callout.html">Callout</a></li>
 <li class="toctree-l3"><a class="reference internal" href="../heap/heap.html">Heap</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../memory_pool/memory_pool.html">Memory Pools</a></li>
 <li class="toctree-l3"><a class="reference internal" href="../mbuf/mbuf.html">Mbufs</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../msys/msys.html">Msys</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../mqueue/mqueue.html">Mqueue</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../cputime/os_cputime.html">CPU Time</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../time/os_time.html">OS Time</a></li>
 <li class="toctree-l3"><a class="reference internal" href="../sanity/sanity.html">Sanity</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../callout/callout.html">Callout</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../API.html">API</a></li>
 </ul>
 </li>
-<li class="toctree-l2"><a class="reference internal" href="../porting/port_os.html">Porting Mynewt OS</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../../modules/hal/hal.html">Hardware Abstraction</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../porting/port_os.html">Porting Guide</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../../modules/sysinitconfig/sysinitconfig.html">System Configuration</a></li>
 <li class="toctree-l2"><a class="reference internal" href="../../modules/console/console.html">Console</a></li>
-<li class="toctree-l2"><a class="reference internal" href="../../modules/sysinitconfig/sysinitconfig.html">System Configuration and Initialization</a></li>
 </ul>
 </li>
 <li class="toctree-l1"><a class="reference internal" href="../../../network/ble/ble_intro.html">BLE User Guide</a></li>
@@ -293,7 +291,7 @@ <h2>Description<a class="headerlink" href="#description" title="Permalink to thi
 someone else to wake it up.</p>
 <p>Scheduler algorithm is simple: from among the tasks which are ready to
 run, pick the the one with highest priority (lowest numeric value in
-task?s t_prio field), and make its state <em>running</em>.</p>
+task?s <code class="xref c c-member docutils literal notranslate"><span class="pre">t_prio</span></code> field), and make its state <em>running</em>.</p>
 <p>Tasks which are either <em>running</em> or <em>ready to run</em> are kept in linked
 list <code class="docutils literal notranslate"><span class="pre">g_os_run_list</span></code>. This list is ordered by priority.</p>
 <p>Tasks which are <em>sleeping</em> are kept in linked list <code class="docutils literal notranslate"><span class="pre">g_os_sleep_list</span></code>.</p>
@@ -305,20 +303,18 @@ <h2>Description<a class="headerlink" href="#description" title="Permalink to thi
 </div>
 <div class="section" id="api">
 <h2>API<a class="headerlink" href="#api" title="Permalink to this headline">?</a></h2>
-<ul class="simple">
-<li><a class="reference internal" href="../API.html#c.os_sched" title="os_sched"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_sched()</span></code></a></li>
-<li><code class="xref c c-func docutils literal notranslate"><span class="pre">os_arch_ctx_sw()</span></code></li>
-<li><a class="reference internal" href="../API.html#c.os_sched_ctx_sw_hook" title="os_sched_ctx_sw_hook"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_sched_ctx_sw_hook()</span></code></a></li>
-<li><a class="reference internal" href="../API.html#c.os_sched_get_current_task" title="os_sched_get_current_task"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_sched_get_current_task()</span></code></a></li>
-<li><a class="reference internal" href="../API.html#c.os_sched_insert" title="os_sched_insert"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_sched_insert()</span></code></a></li>
-<li><a class="reference internal" href="../API.html#c.os_sched_next_task" title="os_sched_next_task"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_sched_next_task()</span></code></a></li>
-<li><a class="reference internal" href="../API.html#c.os_sched_os_timer_exp" title="os_sched_os_timer_exp"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_sched_os_timer_exp()</span></code></a></li>
-<li><a class="reference internal" href="../API.html#c.os_sched_remove" title="os_sched_remove"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_sched_remove()</span></code></a></li>
-<li><a class="reference internal" href="../API.html#c.os_sched_resort" title="os_sched_resort"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_sched_resort()</span></code></a></li>
-<li><a class="reference internal" href="../API.html#c.os_sched_set_current_task" title="os_sched_set_current_task"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_sched_set_current_task()</span></code></a></li>
-<li><a class="reference internal" href="../API.html#c.os_sched_sleep" title="os_sched_sleep"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_sched_sleep()</span></code></a></li>
-<li><a class="reference internal" href="../API.html#c.os_sched_wakeup" title="os_sched_wakeup"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_sched_wakeup()</span></code></a></li>
-</ul>
+<dl class="function">
+<dt id="c.os_sched_get_current_task">
+<span class="target" id="group___o_s_sched_1gae76543413dbb2abc71c8236da4e93cfb"></span>struct os_task* <code class="descname">os_sched_get_current_task</code><span class="sig-paren">(</span>void<span class="sig-paren">)</span><a class="headerlink" href="#c.os_sched_get_current_task" title="Permalink to this definition">?</a></dt>
+<dd><p>Returns the currently running task. </p>
+<p>Note that this task may or may not be the highest priority task ready to run.</p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>The currently running task. </dd>
+</dl>
+</p>
+</dd></dl>
+
 </div>
 </div>
 
@@ -328,10 +324,10 @@ <h2>API<a class="headerlink" href="#api" title="Permalink to this headline">?</
                   
     <div class="rst-footer-buttons row" role="navigation" aria-label="footer navigation">
       
-        <a href="../cputime/os_cputime.html" class="btn btn-neutral float-right" title="CPU Time" accesskey="n">Next: CPU Time <span class="fa fa-arrow-circle-right"></span></a>
+        <a href="../task/task.html" class="btn btn-neutral float-right" title="Task" accesskey="n">Next: Task <span class="fa fa-arrow-circle-right"></span></a>
       
       
-        <a href="../mynewt_os.html" class="btn btn-neutral" title="Mynewt Core OS" accesskey="p"><span class="fa fa-arrow-circle-left"></span> Previous: Mynewt Core OS</a>
+        <a href="../mynewt_os.html" class="btn btn-neutral" title="Apache Mynewt Operating System Kernel" accesskey="p"><span class="fa fa-arrow-circle-left"></span> Previous: Apache Mynewt Operating System Kernel</a>
       
     </div>
 
diff --git a/develop/os/core_os/cputime/os_cputime.html b/develop/os/core_os/cputime/os_cputime.html
index 1abcc018c..7142f18dd 100644
--- a/develop/os/core_os/cputime/os_cputime.html
+++ b/develop/os/core_os/cputime/os_cputime.html
@@ -41,9 +41,9 @@
                 href="../../../genindex.html"/>
           <link rel="search" title="Search" href="../../../search.html"/>
       <link rel="top" title="Apache Mynewt 1.3.0 documentation" href="../../../index.html"/>
-          <link rel="up" title="Mynewt Core OS" href="../mynewt_os.html"/>
+          <link rel="up" title="Apache Mynewt Operating System Kernel" href="../mynewt_os.html"/>
           <link rel="next" title="OS Time" href="../time/os_time.html"/>
-          <link rel="prev" title="Scheduler" href="../context_switch/context_switch.html"/> 
+          <link rel="prev" title="Mbufs" href="../mbuf/mbuf.html"/> 
 
     
     <script src="../../../_static/js/modernizr.min.js"></script>
@@ -156,7 +156,7 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
     
       <a href="../../os_user_guide.html">OS User Guide</a> /
     
-      <a href="../mynewt_os.html">Mynewt Core OS</a> /
+      <a href="../mynewt_os.html">Apache Mynewt Operating System Kernel</a> /
     
     CPU Time
     
@@ -224,27 +224,25 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
 <li class="toctree-l1"><a class="reference internal" href="../../../concepts.html">Concepts</a></li>
 <li class="toctree-l1"><a class="reference internal" href="../../../tutorials/tutorials.html">Tutorials</a></li>
 <li class="toctree-l1 current"><a class="reference internal" href="../../os_user_guide.html">OS User Guide</a><ul class="current">
-<li class="toctree-l2 current"><a class="reference internal" href="../mynewt_os.html">OS Core</a><ul class="current">
+<li class="toctree-l2 current"><a class="reference internal" href="../mynewt_os.html">Kernel</a><ul class="current">
 <li class="toctree-l3"><a class="reference internal" href="../context_switch/context_switch.html">Scheduler</a></li>
-<li class="toctree-l3 current"><a class="current reference internal" href="#">CPU Time</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../time/os_time.html">OS Time</a></li>
 <li class="toctree-l3"><a class="reference internal" href="../task/task.html">Task</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../event_queue/event_queue.html">Event Queues</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../semaphore/semaphore.html">Semaphore</a></li>
 <li class="toctree-l3"><a class="reference internal" href="../mutex/mutex.html">Mutex</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../memory_pool/memory_pool.html">Memory Pools</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../semaphore/semaphore.html">Semaphore</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../event_queue/event_queue.html">Event Queues</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../callout/callout.html">Callout</a></li>
 <li class="toctree-l3"><a class="reference internal" href="../heap/heap.html">Heap</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../memory_pool/memory_pool.html">Memory Pools</a></li>
 <li class="toctree-l3"><a class="reference internal" href="../mbuf/mbuf.html">Mbufs</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../msys/msys.html">Msys</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../mqueue/mqueue.html">Mqueue</a></li>
+<li class="toctree-l3 current"><a class="current reference internal" href="#">CPU Time</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../time/os_time.html">OS Time</a></li>
 <li class="toctree-l3"><a class="reference internal" href="../sanity/sanity.html">Sanity</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../callout/callout.html">Callout</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../API.html">API</a></li>
 </ul>
 </li>
-<li class="toctree-l2"><a class="reference internal" href="../porting/port_os.html">Porting Mynewt OS</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../../modules/hal/hal.html">Hardware Abstraction</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../porting/port_os.html">Porting Guide</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../../modules/sysinitconfig/sysinitconfig.html">System Configuration</a></li>
 <li class="toctree-l2"><a class="reference internal" href="../../modules/console/console.html">Console</a></li>
-<li class="toctree-l2"><a class="reference internal" href="../../modules/sysinitconfig/sysinitconfig.html">System Configuration and Initialization</a></li>
 </ul>
 </li>
 <li class="toctree-l1"><a class="reference internal" href="../../../network/ble/ble_intro.html">BLE User Guide</a></li>
@@ -285,42 +283,245 @@ <h1>CPU Time<a class="headerlink" href="#cpu-time" title="Permalink to this head
 <div class="section" id="description">
 <h2>Description<a class="headerlink" href="#description" title="Permalink to this headline">?</a></h2>
 <p>The <code class="docutils literal notranslate"><span class="pre">cputime</span></code> API provides high resolution time and timer support. The
-module must be initialized, using the <code class="docutils literal notranslate"><span class="pre">os_cputime_init()</span></code> function,
+module must be initialized, using the <a class="reference internal" href="#c.os_cputime_init" title="os_cputime_init"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_cputime_init()</span></code></a> function,
 with the clock frequency to use. The module uses the <code class="docutils literal notranslate"><span class="pre">hal_timer</span></code> API,
 defined in hal/hal_timer.h, to access the hardware timers. It uses the
 hardware timer number specified by the <code class="docutils literal notranslate"><span class="pre">OS_CPUTIME_TIMER_NUM</span></code> system
 configuration setting.</p>
 </div>
-<div class="section" id="data-structures">
-<h2>Data Structures<a class="headerlink" href="#data-structures" title="Permalink to this headline">?</a></h2>
-<p>The module uses the following data structures:</p>
-<ul class="simple">
-<li><code class="docutils literal notranslate"><span class="pre">uint32_t</span></code> to represent <code class="docutils literal notranslate"><span class="pre">cputime</span></code>. Only the lower 32 bits of a 64
-timer are used.</li>
-<li><code class="docutils literal notranslate"><span class="pre">struct</span> <span class="pre">hal_timer</span></code> to represent a cputime timer.</li>
-</ul>
-</div>
 <div class="section" id="api">
 <h2>API<a class="headerlink" href="#api" title="Permalink to this headline">?</a></h2>
-<ul class="simple">
-<li><a class="reference internal" href="../API.html#c.os_cputime_delay_nsecs" title="os_cputime_delay_nsecs"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_cputime_delay_nsecs()</span></code></a></li>
-<li><a class="reference internal" href="../API.html#c.os_cputime_delay_ticks" title="os_cputime_delay_ticks"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_cputime_delay_ticks()</span></code></a></li>
-<li><a class="reference internal" href="../API.html#c.os_cputime_delay_usecs" title="os_cputime_delay_usecs"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_cputime_delay_usecs()</span></code></a></li>
-<li><a class="reference internal" href="../API.html#c.os_cputime_get32" title="os_cputime_get32"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_cputime_get32()</span></code></a></li>
-<li><a class="reference internal" href="../API.html#c.os_cputime_init" title="os_cputime_init"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_cputime_init()</span></code></a></li>
-<li><a class="reference internal" href="../API.html#c.os_cputime_nsecs_to_ticks" title="os_cputime_nsecs_to_ticks"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_cputime_nsecs_to_ticks()</span></code></a></li>
-<li><a class="reference internal" href="../API.html#c.os_cputime_ticks_to_nsecs" title="os_cputime_ticks_to_nsecs"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_cputime_ticks_to_nsecs()</span></code></a></li>
-<li><a class="reference internal" href="../API.html#c.os_cputime_ticks_to_usecs" title="os_cputime_ticks_to_usecs"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_cputime_ticks_to_usecs()</span></code></a></li>
-<li><a class="reference internal" href="../API.html#c.os_cputime_timer_init" title="os_cputime_timer_init"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_cputime_timer_init()</span></code></a></li>
-<li><a class="reference internal" href="../API.html#c.os_cputime_timer_relative" title="os_cputime_timer_relative"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_cputime_timer_relative()</span></code></a></li>
-<li><a class="reference internal" href="../API.html#c.os_cputime_timer_start" title="os_cputime_timer_start"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_cputime_timer_start()</span></code></a></li>
-<li><a class="reference internal" href="../API.html#c.os_cputime_timer_stop" title="os_cputime_timer_stop"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_cputime_timer_stop()</span></code></a></li>
-<li><a class="reference internal" href="../API.html#c.os_cputime_usecs_to_ticks" title="os_cputime_usecs_to_ticks"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_cputime_usecs_to_ticks()</span></code></a></li>
-<li><a class="reference internal" href="../API.html#c.CPUTIME_LT" title="CPUTIME_LT"><code class="xref c c-macro docutils literal notranslate"><span class="pre">CPUTIME_LT</span></code></a></li>
-<li><a class="reference internal" href="../API.html#c.CPUTIME_GT" title="CPUTIME_GT"><code class="xref c c-macro docutils literal notranslate"><span class="pre">CPUTIME_GT</span></code></a></li>
-<li><a class="reference internal" href="../API.html#c.CPUTIME_LEQ" title="CPUTIME_LEQ"><code class="xref c c-macro docutils literal notranslate"><span class="pre">CPUTIME_LEQ</span></code></a></li>
-<li><a class="reference internal" href="../API.html#c.CPUTIME_GEQ" title="CPUTIME_GEQ"><code class="xref c c-macro docutils literal notranslate"><span class="pre">CPUTIME_GEQ</span></code></a></li>
+<dl class="function">
+<dt id="c.os_cputime_init">
+<span class="target" id="group___o_s_c_p_u_time_1ga7aa50ce2ac6e1dae6bed02647822f358"></span>int <code class="descname">os_cputime_init</code><span class="sig-paren">(</span>uint32_t<em>&nbsp;clock_freq</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_cputime_init" title="Permalink to this definition">?</a></dt>
+<dd><p>Initialize the cputime module. </p>
+<p>This must be called after os_init is called and before any other timer API are used. This should be called only once and should be called before the hardware timer is used.</p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>int 0 on success; -1 on error. </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">clock_freq</span></code>: The desired cputime frequency, in hertz (Hz).</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_cputime_get32">
+<span class="target" id="group___o_s_c_p_u_time_1gafb6a952579e92ce3356df29991aaa9f5"></span>uint32_t <code class="descname">os_cputime_get32</code><span class="sig-paren">(</span>void<span class="sig-paren">)</span><a class="headerlink" href="#c.os_cputime_get32" title="Permalink to this definition">?</a></dt>
+<dd><p>Returns the low 32 bits of cputime. </p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>uint32_t The lower 32 bits of cputime </dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_cputime_nsecs_to_ticks">
+<span class="target" id="group___o_s_c_p_u_time_1gafb439dfff3071b7c294fcf33929470fa"></span>uint32_t <code class="descname">os_cputime_nsecs_to_ticks</code><span class="sig-paren">(</span>uint32_t<em>&nbsp;nsecs</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_cputime_nsecs_to_ticks" title="Permalink to this definition">?</a></dt>
+<dd><p>Converts the given number of nanoseconds into cputime ticks. </p>
+<p>Not defined if OS_CPUTIME_FREQ_PWR2 is defined.</p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>uint32_t The number of ticks corresponding to ?nsecs? </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">usecs</span></code>: The number of nanoseconds to convert to ticks</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_cputime_ticks_to_nsecs">
+<span class="target" id="group___o_s_c_p_u_time_1ga8643177f7b726a6e16eb9304849b89df"></span>uint32_t <code class="descname">os_cputime_ticks_to_nsecs</code><span class="sig-paren">(</span>uint32_t<em>&nbsp;ticks</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_cputime_ticks_to_nsecs" title="Permalink to this definition">?</a></dt>
+<dd><p>Convert the given number of ticks into nanoseconds. </p>
+<p>Not defined if OS_CPUTIME_FREQ_PWR2 is defined.</p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>uint32_t The number of nanoseconds corresponding to ?ticks? </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">ticks</span></code>: The number of ticks to convert to nanoseconds.</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_cputime_delay_nsecs">
+<span class="target" id="group___o_s_c_p_u_time_1gab604f54b3bef695127d93738adc09632"></span>void <code class="descname">os_cputime_delay_nsecs</code><span class="sig-paren">(</span>uint32_t<em>&nbsp;nsecs</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_cputime_delay_nsecs" title="Permalink to this definition">?</a></dt>
+<dd><p>Wait until ?nsecs? nanoseconds has elapsed. </p>
+<p>This is a blocking delay. Not defined if OS_CPUTIME_FREQ_PWR2 is defined.</p>
+<p><dl class="docutils">
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">nsecs</span></code>: The number of nanoseconds to wait. </li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_cputime_usecs_to_ticks">
+<span class="target" id="group___o_s_c_p_u_time_1gaa54a2647142c5104ab507da518b7c51a"></span>uint32_t <code class="descname">os_cputime_usecs_to_ticks</code><span class="sig-paren">(</span>uint32_t<em>&nbsp;usecs</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_cputime_usecs_to_ticks" title="Permalink to this definition">?</a></dt>
+<dd><p>Converts the given number of microseconds into cputime ticks. </p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>uint32_t The number of ticks corresponding to ?usecs? </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">usecs</span></code>: The number of microseconds to convert to ticks</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_cputime_ticks_to_usecs">
+<span class="target" id="group___o_s_c_p_u_time_1ga359fa2d0037720cf7c485c9c2c811a4b"></span>uint32_t <code class="descname">os_cputime_ticks_to_usecs</code><span class="sig-paren">(</span>uint32_t<em>&nbsp;ticks</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_cputime_ticks_to_usecs" title="Permalink to this definition">?</a></dt>
+<dd><p>Convert the given number of ticks into microseconds. </p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>uint32_t The number of microseconds corresponding to ?ticks? </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">ticks</span></code>: The number of ticks to convert to microseconds.</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_cputime_delay_ticks">
+<span class="target" id="group___o_s_c_p_u_time_1gacb8a96b8a28174810a1d1030abbccc62"></span>void <code class="descname">os_cputime_delay_ticks</code><span class="sig-paren">(</span>uint32_t<em>&nbsp;ticks</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_cputime_delay_ticks" title="Permalink to this definition">?</a></dt>
+<dd><p>Wait until the number of ticks has elapsed. </p>
+<p>This is a blocking delay.</p>
+<p><dl class="docutils">
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">ticks</span></code>: The number of ticks to wait. </li>
 </ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_cputime_delay_usecs">
+<span class="target" id="group___o_s_c_p_u_time_1ga5d02f111807229adcbe1a63f6bcd6dfd"></span>void <code class="descname">os_cputime_delay_usecs</code><span class="sig-paren">(</span>uint32_t<em>&nbsp;usecs</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_cputime_delay_usecs" title="Permalink to this definition">?</a></dt>
+<dd><p>Wait until ?usecs? microseconds has elapsed. </p>
+<p>This is a blocking delay.</p>
+<p><dl class="docutils">
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">usecs</span></code>: The number of usecs to wait. </li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_cputime_timer_init">
+<span class="target" id="group___o_s_c_p_u_time_1gaaa77925d4b99f92de3fdb3a33763f3ee"></span>void <code class="descname">os_cputime_timer_init</code><span class="sig-paren">(</span>struct  hal_timer  *<em>&nbsp;timer</em>, <a class="reference internal" href="../../modules/hal/hal_timer/hal_timer.html#c.hal_timer_cb" title="hal_timer_cb">hal_timer_cb</a><em>&nbsp;fp</em>, void *<em>&nbsp;arg</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_cputime_timer_init" title="Permalink to this definition">?</a></dt>
+<dd><p>Initialize a CPU timer, using the given HAL timer. </p>
+<p><dl class="docutils">
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">timer</span></code>: The timer to initialize. Cannot be NULL. </li>
+<li><code class="docutils literal notranslate"><span class="pre">fp</span></code>: The timer callback function. Cannot be NULL. </li>
+<li><code class="docutils literal notranslate"><span class="pre">arg</span></code>: Pointer to data object to pass to timer. </li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_cputime_timer_start">
+<span class="target" id="group___o_s_c_p_u_time_1ga7ee4efebfb9ace6abc53aab7befbb36b"></span>int <code class="descname">os_cputime_timer_start</code><span class="sig-paren">(</span>struct  hal_timer  *<em>&nbsp;timer</em>, uint32_t<em>&nbsp;cputime</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_cputime_timer_start" title="Permalink to this definition">?</a></dt>
+<dd><p>Start a cputimer that will expire at ?cputime?. </p>
+<p>If cputime has already passed, the timer callback will still be called (at interrupt context).</p>
+<p>NOTE: This must be called when the timer is stopped.</p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>int 0 on success; EINVAL if timer already started or timer struct invalid </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">timer</span></code>: Pointer to timer to start. Cannot be NULL. </li>
+<li><code class="docutils literal notranslate"><span class="pre">cputime</span></code>: The cputime at which the timer should expire.</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_cputime_timer_relative">
+<span class="target" id="group___o_s_c_p_u_time_1ga178a0ad1206ee2f3921ec812cc4dbd93"></span>int <code class="descname">os_cputime_timer_relative</code><span class="sig-paren">(</span>struct  hal_timer  *<em>&nbsp;timer</em>, uint32_t<em>&nbsp;usecs</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_cputime_timer_relative" title="Permalink to this definition">?</a></dt>
+<dd><p>Sets a cpu timer that will expire ?usecs? microseconds from the current cputime. </p>
+<p>NOTE: This must be called when the timer is stopped.</p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>int 0 on success; EINVAL if timer already started or timer struct invalid </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">timer</span></code>: Pointer to timer. Cannot be NULL. </li>
+<li><code class="docutils literal notranslate"><span class="pre">usecs</span></code>: The number of usecs from now at which the timer will expire.</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_cputime_timer_stop">
+<span class="target" id="group___o_s_c_p_u_time_1ga941919d476b402d1afd0d23f1b1e06fe"></span>void <code class="descname">os_cputime_timer_stop</code><span class="sig-paren">(</span>struct  hal_timer  *<em>&nbsp;timer</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_cputime_timer_stop" title="Permalink to this definition">?</a></dt>
+<dd><p>Stops a cputimer from running. </p>
+<p>The timer is removed from the timer queue and interrupts are disabled if no timers are left on the queue. Can be called even if timer is not running.</p>
+<p><dl class="docutils">
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">timer</span></code>: Pointer to cputimer to stop. Cannot be NULL. </li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="define">
+<dt id="c.CPUTIME_LT">
+<span class="target" id="group___o_s_c_p_u_time_1ga4309205f199bb636919dbfc5d73ef12e"></span><code class="descname">CPUTIME_LT</code><span class="sig-paren">(</span>__t1, __t2<span class="sig-paren">)</span><a class="headerlink" href="#c.CPUTIME_LT" title="Permalink to this definition">?</a></dt>
+<dd><p>evaluates to true if t1 is before t2 in time </p>
+</dd></dl>
+
+<dl class="define">
+<dt id="c.CPUTIME_GT">
+<span class="target" id="group___o_s_c_p_u_time_1gadad5099542aece9275da4d725eb480ac"></span><code class="descname">CPUTIME_GT</code><span class="sig-paren">(</span>__t1, __t2<span class="sig-paren">)</span><a class="headerlink" href="#c.CPUTIME_GT" title="Permalink to this definition">?</a></dt>
+<dd><p>evaluates to true if t1 is after t2 in time </p>
+</dd></dl>
+
+<dl class="define">
+<dt id="c.CPUTIME_GEQ">
+<span class="target" id="group___o_s_c_p_u_time_1gab2d4411ac9afee90785a47fcb9b0667f"></span><code class="descname">CPUTIME_GEQ</code><span class="sig-paren">(</span>__t1, __t2<span class="sig-paren">)</span><a class="headerlink" href="#c.CPUTIME_GEQ" title="Permalink to this definition">?</a></dt>
+<dd><p>evaluates to true if t1 is after t2 in time </p>
+</dd></dl>
+
+<dl class="define">
+<dt id="c.CPUTIME_LEQ">
+<span class="target" id="group___o_s_c_p_u_time_1gad1fc43d68f68ce9a60261f94864cdfdd"></span><code class="descname">CPUTIME_LEQ</code><span class="sig-paren">(</span>__t1, __t2<span class="sig-paren">)</span><a class="headerlink" href="#c.CPUTIME_LEQ" title="Permalink to this definition">?</a></dt>
+<dd><p>evaluates to true if t1 is on or after t2 in time </p>
+</dd></dl>
+
 </div>
 </div>
 
@@ -333,7 +534,7 @@ <h2>API<a class="headerlink" href="#api" title="Permalink to this headline">?</
         <a href="../time/os_time.html" class="btn btn-neutral float-right" title="OS Time" accesskey="n">Next: OS Time <span class="fa fa-arrow-circle-right"></span></a>
       
       
-        <a href="../context_switch/context_switch.html" class="btn btn-neutral" title="Scheduler" accesskey="p"><span class="fa fa-arrow-circle-left"></span> Previous: Scheduler</a>
+        <a href="../mbuf/mbuf.html" class="btn btn-neutral" title="Mbufs" accesskey="p"><span class="fa fa-arrow-circle-left"></span> Previous: Mbufs</a>
       
     </div>
 
diff --git a/develop/os/core_os/event_queue/event_queue.html b/develop/os/core_os/event_queue/event_queue.html
index 58ecd1d65..cc4cc27e2 100644
--- a/develop/os/core_os/event_queue/event_queue.html
+++ b/develop/os/core_os/event_queue/event_queue.html
@@ -41,9 +41,9 @@
                 href="../../../genindex.html"/>
           <link rel="search" title="Search" href="../../../search.html"/>
       <link rel="top" title="Apache Mynewt 1.3.0 documentation" href="../../../index.html"/>
-          <link rel="up" title="Mynewt Core OS" href="../mynewt_os.html"/>
-          <link rel="next" title="Semaphore" href="../semaphore/semaphore.html"/>
-          <link rel="prev" title="Task" href="../task/task.html"/> 
+          <link rel="up" title="Apache Mynewt Operating System Kernel" href="../mynewt_os.html"/>
+          <link rel="next" title="Callout" href="../callout/callout.html"/>
+          <link rel="prev" title="Semaphore" href="../semaphore/semaphore.html"/> 
 
     
     <script src="../../../_static/js/modernizr.min.js"></script>
@@ -156,7 +156,7 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
     
       <a href="../../os_user_guide.html">OS User Guide</a> /
     
-      <a href="../mynewt_os.html">Mynewt Core OS</a> /
+      <a href="../mynewt_os.html">Apache Mynewt Operating System Kernel</a> /
     
     Event Queues
     
@@ -224,27 +224,25 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
 <li class="toctree-l1"><a class="reference internal" href="../../../concepts.html">Concepts</a></li>
 <li class="toctree-l1"><a class="reference internal" href="../../../tutorials/tutorials.html">Tutorials</a></li>
 <li class="toctree-l1 current"><a class="reference internal" href="../../os_user_guide.html">OS User Guide</a><ul class="current">
-<li class="toctree-l2 current"><a class="reference internal" href="../mynewt_os.html">OS Core</a><ul class="current">
+<li class="toctree-l2 current"><a class="reference internal" href="../mynewt_os.html">Kernel</a><ul class="current">
 <li class="toctree-l3"><a class="reference internal" href="../context_switch/context_switch.html">Scheduler</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../cputime/os_cputime.html">CPU Time</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../time/os_time.html">OS Time</a></li>
 <li class="toctree-l3"><a class="reference internal" href="../task/task.html">Task</a></li>
-<li class="toctree-l3 current"><a class="current reference internal" href="#">Event Queues</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../semaphore/semaphore.html">Semaphore</a></li>
 <li class="toctree-l3"><a class="reference internal" href="../mutex/mutex.html">Mutex</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../memory_pool/memory_pool.html">Memory Pools</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../semaphore/semaphore.html">Semaphore</a></li>
+<li class="toctree-l3 current"><a class="current reference internal" href="#">Event Queues</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../callout/callout.html">Callout</a></li>
 <li class="toctree-l3"><a class="reference internal" href="../heap/heap.html">Heap</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../memory_pool/memory_pool.html">Memory Pools</a></li>
 <li class="toctree-l3"><a class="reference internal" href="../mbuf/mbuf.html">Mbufs</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../msys/msys.html">Msys</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../mqueue/mqueue.html">Mqueue</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../cputime/os_cputime.html">CPU Time</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../time/os_time.html">OS Time</a></li>
 <li class="toctree-l3"><a class="reference internal" href="../sanity/sanity.html">Sanity</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../callout/callout.html">Callout</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../API.html">API</a></li>
 </ul>
 </li>
-<li class="toctree-l2"><a class="reference internal" href="../porting/port_os.html">Porting Mynewt OS</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../../modules/hal/hal.html">Hardware Abstraction</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../porting/port_os.html">Porting Guide</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../../modules/sysinitconfig/sysinitconfig.html">System Configuration</a></li>
 <li class="toctree-l2"><a class="reference internal" href="../../modules/console/console.html">Console</a></li>
-<li class="toctree-l2"><a class="reference internal" href="../../modules/sysinitconfig/sysinitconfig.html">System Configuration and Initialization</a></li>
 </ul>
 </li>
 <li class="toctree-l1"><a class="reference internal" href="../../../network/ble/ble_intro.html">BLE User Guide</a></li>
@@ -283,9 +281,8 @@ <h1>Event Queues<a class="headerlink" href="#event-queues" title="Permalink to t
 <p>An event queue allows a task to serialize incoming events and simplify
 event processing. Events are stored in a queue and a task removes and
 processes an event from the queue. An event is processed in the context
-of this task. Events may be generated by <a class="reference external" href="../callout/callout.html">OS
-callouts</a>, interrupt handlers, and other
-tasks.</p>
+of this task. Events may be generated by OS callouts, interrupt handlers,
+and other tasks.</p>
 <div class="section" id="description">
 <h2>Description<a class="headerlink" href="#description" title="Permalink to this headline">?</a></h2>
 <p>Mynewt?s event queue model uses callback functions to process events.
@@ -306,88 +303,34 @@ <h2>Description<a class="headerlink" href="#description" title="Permalink to thi
 for its events. The callback function for an event from the Mynewt
 default event queue is executed in the context of the application main
 task. A package can, optionally, export a function that allows an
-application to specify the event queue for the package to use. (See the
-example in the <code class="docutils literal notranslate"><span class="pre">os_eventq_designate()</span></code> function description on how to
-write such a function.) The application task handler that manages the
-event queue simply pulls events from the event queue and executes the
-event?s callback function in its context.</p>
+application to specify the event queue for the package to use. The
+application task handler that manages the event queue simply pulls events
+from the event queue and executes the event?s callback function in its context.</p>
 <p>A common way that Mynewt applications or packages process events from an
 event queue is to have a task that executes in an infinite loop and
-calls the <code class="docutils literal notranslate"><span class="pre">os_eventq_get()</span></code> function to dequeue and return the event
+calls the <a class="reference internal" href="#c.os_eventq_get" title="os_eventq_get"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_eventq_get()</span></code></a> function to dequeue and return the event
 from the head of the event queue. The task then calls the event callback
-function to process the event. The <code class="docutils literal notranslate"><span class="pre">os_eventq_get()</span></code> function puts the
+function to process the event. The <a class="reference internal" href="#c.os_eventq_get" title="os_eventq_get"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_eventq_get()</span></code></a> function puts the
 task in to the <code class="docutils literal notranslate"><span class="pre">sleeping</span></code> state when there are no events on the queue.
-(See <a class="reference external" href="../context_switch/context_switch.html">Scheduler</a> for more
+(See <a class="reference internal" href="../context_switch/context_switch.html"><span class="doc">Scheduler</span></a> for more
 information on task execution states.) Other tasks (or interrupts) call
-the <code class="docutils literal notranslate"><span class="pre">os_eventq_put()</span></code> function to add an event to the queue. The
-<code class="docutils literal notranslate"><span class="pre">os_eventq_put()</span></code> function determines whether a task is blocked
+the <a class="reference internal" href="#c.os_eventq_put" title="os_eventq_put"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_eventq_put()</span></code></a> function to add an event to the queue. The
+<a class="reference internal" href="#c.os_eventq_put" title="os_eventq_put"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_eventq_put()</span></code></a> function determines whether a task is blocked
 waiting for an event on the queue and puts the task into the
 <code class="docutils literal notranslate"><span class="pre">ready-to-run</span></code> state.</p>
-<p>A task can use the <code class="docutils literal notranslate"><span class="pre">os_eventq_run()</span></code> wrapper function that calls the
-<code class="docutils literal notranslate"><span class="pre">os_eventq_get()</span></code> function to dequeue an event from the queue and then
-calls the event callback function to process the event.</p>
-<p>Note:</p>
+<p>A task can use the <a class="reference internal" href="#c.os_eventq_run" title="os_eventq_run"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_eventq_run()</span></code></a> wrapper function that calls the
+<a class="reference internal" href="#c.os_eventq_get" title="os_eventq_get"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_eventq_get()</span></code></a> function to dequeue an event from the queue and then
+calls the event callback function to process the event.
+Note:</p>
 <ul class="simple">
 <li>Only one task should consume or block waiting for events from an
 event queue.</li>
-<li>The <a class="reference external" href="../callout/callout.html">os_callout</a> subsystem uses events for
-timer expiration notification.</li>
+<li>The OS callout subsystem uses events for timer expiration notification.</li>
 </ul>
 </div>
-<div class="section" id="data-structures">
-<h2>Data structures<a class="headerlink" href="#data-structures" title="Permalink to this headline">?</a></h2>
-<p>The <code class="docutils literal notranslate"><span class="pre">os_event</span></code> structure defines an event and has the following
-fields:</p>
-<div class="code c highlight-none notranslate"><div class="highlight"><pre><span></span>struct os_event {
-    uint8_t ev_queued;
-    os_event_fn *ev_cb;
-    void *ev_arg;
-    STAILQ_ENTRY(os_event) ev_next;
-};
-</pre></div>
-</div>
-<table border="1" class="docutils">
-<colgroup>
-<col width="16%" />
-<col width="84%" />
-</colgroup>
-<thead valign="bottom">
-<tr class="row-odd"><th class="head">Element</th>
-<th class="head">Description</th>
-</tr>
-</thead>
-<tbody valign="top">
-<tr class="row-even"><td><code class="docutils literal notranslate"><span class="pre">ev_queued</span></code></td>
-<td>Internal field that indicates whether this event is currently linked to an event queue</td>
-</tr>
-<tr class="row-odd"><td><code class="docutils literal notranslate"><span class="pre">ev_cb</span></code></td>
-<td>Pointer to the callback function to call to process this event</td>
-</tr>
-<tr class="row-even"><td><code class="docutils literal notranslate"><span class="pre">ev_arg</span></code></td>
-<td>Pointer to an optional opaque data that the callback function uses to process this event</td>
-</tr>
-<tr class="row-odd"><td><code class="docutils literal notranslate"><span class="pre">ev_next</span></code></td>
-<td>Linkage attaching this event to an event queue</td>
-</tr>
-</tbody>
-</table>
-<p>An event callback function has the following function prototype:</p>
-<div class="code c highlight-none notranslate"><div class="highlight"><pre><span></span>typedef void os_event_fn(struct os_event *ev);
-</pre></div>
-</div>
-<p>A pointer to the <code class="docutils literal notranslate"><span class="pre">os_event</span></code> structure for the event is passed as an
-argument to the callback function.</p>
-<p>Notes: If the memory for the <code class="docutils literal notranslate"><span class="pre">os_event</span></code> structure is dynamically
-allocated:</p>
-<ul class="simple">
-<li>You must not free the memory for an event that is currently on an
-event queue.</li>
-<li>You must free the memory in the callback function after it completes
-processing the event.</li>
-</ul>
-<p>You must set the callback function for an event when you initialize the
-event. For example, here is an example of a statically-initialized event
-in the NimBLE host:</p>
+<div class="section" id="example">
+<h2>Example<a class="headerlink" href="#example" title="Permalink to this headline">?</a></h2>
+<p>Here is an example of using an event from the BLE host:</p>
 <div class="code c highlight-none notranslate"><div class="highlight"><pre><span></span>static void ble_hs_event_tx_notify(struct os_event *ev);
 
 /** OS event - triggers tx of pending notifications and indications. */
@@ -396,41 +339,200 @@ <h2>Data structures<a class="headerlink" href="#data-structures" title="Permalin
 };
 </pre></div>
 </div>
-<p>The <code class="docutils literal notranslate"><span class="pre">os_eventq</span></code> structure defines an event queue and has the following fields:</p>
-<div class="code c highlight-none notranslate"><div class="highlight"><pre><span></span>struct os_eventq {
-    struct os_task *evq_task;
-    STAILQ_HEAD(, os_event) evq_list;
-};
-</pre></div>
-</div>
-<table border="1" class="docutils">
-<colgroup>
-<col width="11%" />
-<col width="89%" />
-</colgroup>
-<thead valign="bottom">
-<tr class="row-odd"><th class="head">Element</th>
-<th class="head">Description</th>
-</tr>
-</thead>
-<tbody valign="top">
-<tr class="row-even"><td><code class="docutils literal notranslate"><span class="pre">evq_task</span></code></td>
-<td>Pointer to the task, if any, that is waiting (in the <code class="docutils literal notranslate"><span class="pre">sleeping</span></code> state) for the <code class="docutils literal notranslate"><span class="pre">os_eventq_get()</span></code> function to return an event</td>
-</tr>
-<tr class="row-odd"><td><code class="docutils literal notranslate"><span class="pre">evq_list</span></code></td>
-<td>Head of the list of events in this queue</td>
-</tr>
-</tbody>
-</table>
-<p>You must call the <code class="docutils literal notranslate"><span class="pre">os_eventq_init()</span></code> function to initialize an event
-queue before you can add events to the queue.</p>
 </div>
 <div class="section" id="api">
 <h2>API<a class="headerlink" href="#api" title="Permalink to this headline">?</a></h2>
-<div class="admonition warning">
-<p class="first admonition-title">Warning</p>
-<p class="last">doxygengroup: Cannot find namespace ?OSEvent? in doxygen xml output for project ?mynewt-core? from directory: mynewt-core-xml</p>
+<dl class="typedef">
+<dt id="c.os_event_fn">
+<span class="target" id="group___o_s_event_1ga6e572d40b307b9f40bec72281548b63e"></span><em class="property">typedef </em>void <code class="descname">os_event_fn</code><span class="sig-paren">(</span>struct os_event<em>&nbsp;*ev</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_event_fn" title="Permalink to this definition">?</a></dt>
+<dd></dd></dl>
+
+<dl class="function">
+<dt id="c.os_eventq_init">
+<span class="target" id="group___o_s_event_1ga12330bd028b5efdb00b96f8d85ad576b"></span>void <code class="descname">os_eventq_init</code><span class="sig-paren">(</span>struct  os_eventq <em>&nbsp;*</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_eventq_init" title="Permalink to this definition">?</a></dt>
+<dd><p>Initialize the event queue. </p>
+<p><dl class="docutils">
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">evq</span></code>: The event queue to initialize </li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_eventq_inited">
+<span class="target" id="group___o_s_event_1ga21fb29b6ce469a93d87eacc2c64f7bca"></span>int <code class="descname">os_eventq_inited</code><span class="sig-paren">(</span>const struct  os_eventq  *<em>&nbsp;evq</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_eventq_inited" title="Permalink to this definition">?</a></dt>
+<dd><p>Check whether the event queue is initialized. </p>
+<p><dl class="docutils">
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">evq</span></code>: The event queue to check </li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_eventq_put">
+<span class="target" id="group___o_s_event_1ga00853fd6e0f5bbf39e3930ee70665755"></span>void <code class="descname">os_eventq_put</code><span class="sig-paren">(</span>struct  os_eventq <em>&nbsp;*</em>, struct  os_event <em>&nbsp;*</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_eventq_put" title="Permalink to this definition">?</a></dt>
+<dd><p>Put an event on the event queue. </p>
+<p><dl class="docutils">
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">evq</span></code>: The event queue to put an event on </li>
+<li><code class="docutils literal notranslate"><span class="pre">ev</span></code>: The event to put on the queue </li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_eventq_get_no_wait">
+<span class="target" id="group___o_s_event_1ga5142a879bb51db18fa7ff725a81e13d0"></span>struct os_event* <code class="descname">os_eventq_get_no_wait</code><span class="sig-paren">(</span>struct  os_eventq  *<em>&nbsp;evq</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_eventq_get_no_wait" title="Permalink to this definition">?</a></dt>
+<dd><p>Poll an event from the event queue and return it immediately. </p>
+<p>If no event is available, don?t block, just return NULL.</p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>Event from the queue, or NULL if none available. </dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_eventq_get">
+<span class="target" id="group___o_s_event_1ga5d4a42f82a5fd7c2911ad4cb61a78045"></span>struct os_event* <code class="descname">os_eventq_get</code><span class="sig-paren">(</span>struct  os_eventq <em>&nbsp;*</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_eventq_get" title="Permalink to this definition">?</a></dt>
+<dd><p>Pull a single item from an event queue. </p>
+<p>This function blocks until there is an item on the event queue to read.</p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>The event from the queue </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">evq</span></code>: The event queue to pull an event from</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_eventq_run">
+<span class="target" id="group___o_s_event_1ga5ccd457fe11fddc18f30e9155167948f"></span>void <code class="descname">os_eventq_run</code><span class="sig-paren">(</span>struct  os_eventq  *<em>&nbsp;evq</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_eventq_run" title="Permalink to this definition">?</a></dt>
+<dd><p>Pull a single item off the event queue and call it?s event callback. </p>
+<p><dl class="docutils">
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">evq</span></code>: The event queue to pull the item off. </li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_eventq_poll">
+<span class="target" id="group___o_s_event_1ga75902d07b868e820357767c4aae2e175"></span>struct os_event* <code class="descname">os_eventq_poll</code><span class="sig-paren">(</span>struct  os_eventq <em>&nbsp;**</em>, int, <a class="reference internal" href="../time/os_time.html#c.os_time_t" title="os_time_t">os_time_t</a><span class="sig-paren">)</span><a class="headerlink" href="#c.os_eventq_poll" title="Permalink to this definition">?</a></dt>
+<dd><p>Poll the list of event queues specified by the evq parameter (size nevqs), and return the ?first? event available on any of the queues. </p>
+<p>Event queues are searched in the order that they are passed in the array.</p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>An event, or NULL if no events available </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">evq</span></code>: Array of event queues </li>
+<li><code class="docutils literal notranslate"><span class="pre">nevqs</span></code>: Number of event queues in evq </li>
+<li><code class="docutils literal notranslate"><span class="pre">timo</span></code>: Timeout, forever if OS_WAIT_FOREVER is passed to poll.</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_eventq_remove">
+<span class="target" id="group___o_s_event_1ga74c23f0cc51953fa974cfb09e9bb646a"></span>void <code class="descname">os_eventq_remove</code><span class="sig-paren">(</span>struct  os_eventq <em>&nbsp;*</em>, struct  os_event <em>&nbsp;*</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_eventq_remove" title="Permalink to this definition">?</a></dt>
+<dd><p>Remove an event from the queue. </p>
+<p><dl class="docutils">
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">evq</span></code>: The event queue to remove the event from </li>
+<li><code class="docutils literal notranslate"><span class="pre">ev</span></code>: The event to remove from the queue </li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_eventq_dflt_get">
+<span class="target" id="group___o_s_event_1gacb92d16784e50c39fc62c92748d3a72d"></span>struct os_eventq* <code class="descname">os_eventq_dflt_get</code><span class="sig-paren">(</span>void<span class="sig-paren">)</span><a class="headerlink" href="#c.os_eventq_dflt_get" title="Permalink to this definition">?</a></dt>
+<dd><p>Retrieves the default event queue processed by OS main task. </p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>The default event queue. </dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="define">
+<dt id="c.OS_EVENT_QUEUED">
+<span class="target" id="group___o_s_event_1gaf8776b7d4a3a3374e89562eefb3f3df2"></span><code class="descname">OS_EVENT_QUEUED</code><span class="sig-paren">(</span>__ev<span class="sig-paren">)</span><a class="headerlink" href="#c.OS_EVENT_QUEUED" title="Permalink to this definition">?</a></dt>
+<dd><p>Return whether or not the given event is queued. </p>
+</dd></dl>
+
+<dl class="class">
+<dt id="_CPPv38os_event">
+<span id="_CPPv28os_event"></span><span id="os_event"></span><span class="target" id="structos__event"></span><em class="property">struct </em><code class="descname">os_event</code><a class="headerlink" href="#_CPPv38os_event" title="Permalink to this definition">?</a><br /></dt>
+<dd><em>#include &lt;os_eventq.h&gt;</em><p>Structure representing an OS event. </p>
+<p>OS events get placed onto the event queues and are consumed by tasks. </p>
+<div class="breathe-sectiondef docutils container">
+<p class="breathe-sectiondef-title rubric">Public Members</p>
+<dl class="variable">
+<dt id="c.os_event::ev_queued">
+<span class="target" id="structos__event_1a22704177c6946c3bbb9f30dd8dca1b68"></span>uint8_t <code class="descname">ev_queued</code><a class="headerlink" href="#c.os_event::ev_queued" title="Permalink to this definition">?</a></dt>
+<dd><p>Whether this OS event is queued on an event queue. </p>
+</dd></dl>
+
+<dl class="variable">
+<dt id="c.os_event::ev_cb">
+<span class="target" id="structos__event_1adce337a55ab01bf317fcd9048b4fb97d"></span><a class="reference internal" href="#c.os_event_fn" title="os_event_fn">os_event_fn</a>* <code class="descname">ev_cb</code><a class="headerlink" href="#c.os_event::ev_cb" title="Permalink to this definition">?</a></dt>
+<dd><p>Callback to call when the event is taken off of an event queue. </p>
+<p>APIs, except for <a class="reference internal" href="#group___o_s_event_1ga5ccd457fe11fddc18f30e9155167948f"><span class="std std-ref">os_eventq_run()</span></a>, assume this callback will be called by the user. </p>
+</dd></dl>
+
+<dl class="variable">
+<dt id="c.os_event::ev_arg">
+<span class="target" id="structos__event_1affb49e14dcf2b9e1b6f10bac3da788f1"></span>void* <code class="descname">ev_arg</code><a class="headerlink" href="#c.os_event::ev_arg" title="Permalink to this definition">?</a></dt>
+<dd><p>Argument to pass to the event queue callback. </p>
+</dd></dl>
+
+</div>
+</dd></dl>
+
+<dl class="class">
+<dt id="_CPPv39os_eventq">
+<span id="_CPPv29os_eventq"></span><span id="os_eventq"></span><span class="target" id="structos__eventq"></span><em class="property">struct </em><code class="descname">os_eventq</code><a class="headerlink" href="#_CPPv39os_eventq" title="Permalink to this definition">?</a><br /></dt>
+<dd><em>#include &lt;os_eventq.h&gt;</em><div class="breathe-sectiondef docutils container">
+<p class="breathe-sectiondef-title rubric">Public Members</p>
+<dl class="variable">
+<dt id="c.os_eventq::evq_owner">
+<span class="target" id="structos__eventq_1a4f44bc0985277390484d7b5cb6b0e35c"></span>struct os_task* <code class="descname">evq_owner</code><a class="headerlink" href="#c.os_eventq::evq_owner" title="Permalink to this definition">?</a></dt>
+<dd><p>Pointer to task that ?owns? this event queue. </p>
+</dd></dl>
+
+<dl class="variable">
+<dt id="c.os_eventq::evq_task">
+<span class="target" id="structos__eventq_1afba1a5b1c24f170c4fe65c186a9257f8"></span>struct os_task* <code class="descname">evq_task</code><a class="headerlink" href="#c.os_eventq::evq_task" title="Permalink to this definition">?</a></dt>
+<dd><p>Pointer to the task that is sleeping on this event queue, either NULL, or the owner task. </p>
+</dd></dl>
+
 </div>
+</dd></dl>
+
 </div>
 </div>
 
@@ -440,10 +542,10 @@ <h2>API<a class="headerlink" href="#api" title="Permalink to this headline">?</
                   
     <div class="rst-footer-buttons row" role="navigation" aria-label="footer navigation">
       
-        <a href="../semaphore/semaphore.html" class="btn btn-neutral float-right" title="Semaphore" accesskey="n">Next: Semaphore <span class="fa fa-arrow-circle-right"></span></a>
+        <a href="../callout/callout.html" class="btn btn-neutral float-right" title="Callout" accesskey="n">Next: Callout <span class="fa fa-arrow-circle-right"></span></a>
       
       
-        <a href="../task/task.html" class="btn btn-neutral" title="Task" accesskey="p"><span class="fa fa-arrow-circle-left"></span> Previous: Task</a>
+        <a href="../semaphore/semaphore.html" class="btn btn-neutral" title="Semaphore" accesskey="p"><span class="fa fa-arrow-circle-left"></span> Previous: Semaphore</a>
       
     </div>
 
diff --git a/develop/os/core_os/heap/heap.html b/develop/os/core_os/heap/heap.html
index 50de35c18..30d80eaa8 100644
--- a/develop/os/core_os/heap/heap.html
+++ b/develop/os/core_os/heap/heap.html
@@ -41,9 +41,9 @@
                 href="../../../genindex.html"/>
           <link rel="search" title="Search" href="../../../search.html"/>
       <link rel="top" title="Apache Mynewt 1.3.0 documentation" href="../../../index.html"/>
-          <link rel="up" title="Mynewt Core OS" href="../mynewt_os.html"/>
-          <link rel="next" title="Mbufs" href="../mbuf/mbuf.html"/>
-          <link rel="prev" title="Memory Pools" href="../memory_pool/memory_pool.html"/> 
+          <link rel="up" title="Apache Mynewt Operating System Kernel" href="../mynewt_os.html"/>
+          <link rel="next" title="Memory Pools" href="../memory_pool/memory_pool.html"/>
+          <link rel="prev" title="Callout" href="../callout/callout.html"/> 
 
     
     <script src="../../../_static/js/modernizr.min.js"></script>
@@ -156,7 +156,7 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
     
       <a href="../../os_user_guide.html">OS User Guide</a> /
     
-      <a href="../mynewt_os.html">Mynewt Core OS</a> /
+      <a href="../mynewt_os.html">Apache Mynewt Operating System Kernel</a> /
     
     Heap
     
@@ -224,27 +224,25 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
 <li class="toctree-l1"><a class="reference internal" href="../../../concepts.html">Concepts</a></li>
 <li class="toctree-l1"><a class="reference internal" href="../../../tutorials/tutorials.html">Tutorials</a></li>
 <li class="toctree-l1 current"><a class="reference internal" href="../../os_user_guide.html">OS User Guide</a><ul class="current">
-<li class="toctree-l2 current"><a class="reference internal" href="../mynewt_os.html">OS Core</a><ul class="current">
+<li class="toctree-l2 current"><a class="reference internal" href="../mynewt_os.html">Kernel</a><ul class="current">
 <li class="toctree-l3"><a class="reference internal" href="../context_switch/context_switch.html">Scheduler</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../cputime/os_cputime.html">CPU Time</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../time/os_time.html">OS Time</a></li>
 <li class="toctree-l3"><a class="reference internal" href="../task/task.html">Task</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../event_queue/event_queue.html">Event Queues</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../semaphore/semaphore.html">Semaphore</a></li>
 <li class="toctree-l3"><a class="reference internal" href="../mutex/mutex.html">Mutex</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../memory_pool/memory_pool.html">Memory Pools</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../semaphore/semaphore.html">Semaphore</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../event_queue/event_queue.html">Event Queues</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../callout/callout.html">Callout</a></li>
 <li class="toctree-l3 current"><a class="current reference internal" href="#">Heap</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../memory_pool/memory_pool.html">Memory Pools</a></li>
 <li class="toctree-l3"><a class="reference internal" href="../mbuf/mbuf.html">Mbufs</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../msys/msys.html">Msys</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../mqueue/mqueue.html">Mqueue</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../cputime/os_cputime.html">CPU Time</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../time/os_time.html">OS Time</a></li>
 <li class="toctree-l3"><a class="reference internal" href="../sanity/sanity.html">Sanity</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../callout/callout.html">Callout</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../API.html">API</a></li>
 </ul>
 </li>
-<li class="toctree-l2"><a class="reference internal" href="../porting/port_os.html">Porting Mynewt OS</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../../modules/hal/hal.html">Hardware Abstraction</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../porting/port_os.html">Porting Guide</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../../modules/sysinitconfig/sysinitconfig.html">System Configuration</a></li>
 <li class="toctree-l2"><a class="reference internal" href="../../modules/console/console.html">Console</a></li>
-<li class="toctree-l2"><a class="reference internal" href="../../modules/sysinitconfig/sysinitconfig.html">System Configuration and Initialization</a></li>
 </ul>
 </li>
 <li class="toctree-l1"><a class="reference internal" href="../../../network/ble/ble_intro.html">BLE User Guide</a></li>
@@ -285,19 +283,15 @@ <h1>Heap<a class="headerlink" href="#heap" title="Permalink to this headline">?
 <h2>Description<a class="headerlink" href="#description" title="Permalink to this headline">?</a></h2>
 <p>This provides malloc()/free() functionality with locking. The shared
 resource heap needs to be protected from concurrent access when OS has
-been started. <em>os_malloc()</em> function grabs a mutex before calling
-<em>malloc()</em>.</p>
-</div>
-<div class="section" id="data-structures">
-<h2>Data structures<a class="headerlink" href="#data-structures" title="Permalink to this headline">?</a></h2>
-<p>N/A</p>
+been started. <code class="xref c c-func docutils literal notranslate"><span class="pre">os_malloc()</span></code> function grabs a mutex before calling
+<code class="docutils literal notranslate"><span class="pre">malloc()</span></code>.</p>
 </div>
 <div class="section" id="api">
 <h2>API<a class="headerlink" href="#api" title="Permalink to this headline">?</a></h2>
-<p>See the API for OS level function calls.</p>
-<ul class="simple">
-<li><a class="reference external" href="../mynewt_os.html">Mynewt Core OS</a></li>
-</ul>
+<div class="admonition warning">
+<p class="first admonition-title">Warning</p>
+<p class="last">doxygengroup: Cannot find namespace ?OSMalloc? in doxygen xml output for project ?mynewt-core? from directory: mynewt-core-xml</p>
+</div>
 </div>
 </div>
 
@@ -307,10 +301,10 @@ <h2>API<a class="headerlink" href="#api" title="Permalink to this headline">?</
                   
     <div class="rst-footer-buttons row" role="navigation" aria-label="footer navigation">
       
-        <a href="../mbuf/mbuf.html" class="btn btn-neutral float-right" title="Mbufs" accesskey="n">Next: Mbufs <span class="fa fa-arrow-circle-right"></span></a>
+        <a href="../memory_pool/memory_pool.html" class="btn btn-neutral float-right" title="Memory Pools" accesskey="n">Next: Memory Pools <span class="fa fa-arrow-circle-right"></span></a>
       
       
-        <a href="../memory_pool/memory_pool.html" class="btn btn-neutral" title="Memory Pools" accesskey="p"><span class="fa fa-arrow-circle-left"></span> Previous: Memory Pools</a>
+        <a href="../callout/callout.html" class="btn btn-neutral" title="Callout" accesskey="p"><span class="fa fa-arrow-circle-left"></span> Previous: Callout</a>
       
     </div>
 
diff --git a/develop/os/core_os/mbuf/mbuf.html b/develop/os/core_os/mbuf/mbuf.html
index cfa32c327..8edc0ad1f 100644
--- a/develop/os/core_os/mbuf/mbuf.html
+++ b/develop/os/core_os/mbuf/mbuf.html
@@ -41,9 +41,9 @@
                 href="../../../genindex.html"/>
           <link rel="search" title="Search" href="../../../search.html"/>
       <link rel="top" title="Apache Mynewt 1.3.0 documentation" href="../../../index.html"/>
-          <link rel="up" title="Mynewt Core OS" href="../mynewt_os.html"/>
-          <link rel="next" title="Msys" href="../msys/msys.html"/>
-          <link rel="prev" title="Heap" href="../heap/heap.html"/> 
+          <link rel="up" title="Apache Mynewt Operating System Kernel" href="../mynewt_os.html"/>
+          <link rel="next" title="CPU Time" href="../cputime/os_cputime.html"/>
+          <link rel="prev" title="Memory Pools" href="../memory_pool/memory_pool.html"/> 
 
     
     <script src="../../../_static/js/modernizr.min.js"></script>
@@ -156,7 +156,7 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
     
       <a href="../../os_user_guide.html">OS User Guide</a> /
     
-      <a href="../mynewt_os.html">Mynewt Core OS</a> /
+      <a href="../mynewt_os.html">Apache Mynewt Operating System Kernel</a> /
     
     Mbufs
     
@@ -224,27 +224,25 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
 <li class="toctree-l1"><a class="reference internal" href="../../../concepts.html">Concepts</a></li>
 <li class="toctree-l1"><a class="reference internal" href="../../../tutorials/tutorials.html">Tutorials</a></li>
 <li class="toctree-l1 current"><a class="reference internal" href="../../os_user_guide.html">OS User Guide</a><ul class="current">
-<li class="toctree-l2 current"><a class="reference internal" href="../mynewt_os.html">OS Core</a><ul class="current">
+<li class="toctree-l2 current"><a class="reference internal" href="../mynewt_os.html">Kernel</a><ul class="current">
 <li class="toctree-l3"><a class="reference internal" href="../context_switch/context_switch.html">Scheduler</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../cputime/os_cputime.html">CPU Time</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../time/os_time.html">OS Time</a></li>
 <li class="toctree-l3"><a class="reference internal" href="../task/task.html">Task</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../event_queue/event_queue.html">Event Queues</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../semaphore/semaphore.html">Semaphore</a></li>
 <li class="toctree-l3"><a class="reference internal" href="../mutex/mutex.html">Mutex</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../memory_pool/memory_pool.html">Memory Pools</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../semaphore/semaphore.html">Semaphore</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../event_queue/event_queue.html">Event Queues</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../callout/callout.html">Callout</a></li>
 <li class="toctree-l3"><a class="reference internal" href="../heap/heap.html">Heap</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../memory_pool/memory_pool.html">Memory Pools</a></li>
 <li class="toctree-l3 current"><a class="current reference internal" href="#">Mbufs</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../msys/msys.html">Msys</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../mqueue/mqueue.html">Mqueue</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../cputime/os_cputime.html">CPU Time</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../time/os_time.html">OS Time</a></li>
 <li class="toctree-l3"><a class="reference internal" href="../sanity/sanity.html">Sanity</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../callout/callout.html">Callout</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../API.html">API</a></li>
 </ul>
 </li>
-<li class="toctree-l2"><a class="reference internal" href="../porting/port_os.html">Porting Mynewt OS</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../../modules/hal/hal.html">Hardware Abstraction</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../porting/port_os.html">Porting Guide</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../../modules/sysinitconfig/sysinitconfig.html">System Configuration</a></li>
 <li class="toctree-l2"><a class="reference internal" href="../../modules/console/console.html">Console</a></li>
-<li class="toctree-l2"><a class="reference internal" href="../../modules/sysinitconfig/sysinitconfig.html">System Configuration and Initialization</a></li>
 </ul>
 </li>
 <li class="toctree-l1"><a class="reference internal" href="../../../network/ble/ble_intro.html">BLE User Guide</a></li>
@@ -315,11 +313,11 @@ <h2>Packet Header mbuf<a class="headerlink" href="#packet-header-mbuf" title="Pe
 packet (i.e. in the mbuf chain but not the first one) are ?normal? (i.e.
 non-packet header) mbufs. A normal mbuf does not have any packet header
 or user packet header structures in them; they only contain the basic
-mbuf header (<code class="docutils literal notranslate"><span class="pre">struct</span> <span class="pre">os_mbuf</span></code>). Figure 1 illustrates these two types
+mbuf header (<code class="xref c c-type docutils literal notranslate"><span class="pre">struct</span> <span class="pre">os_mbuf</span></code>). Figure 1 illustrates these two types
 of mbufs. Note that the numbers/text in parentheses denote the size of
 the structures/elements (in bytes) and that MBLEN is the memory block
 length of the memory pool used by the mbuf pool.</p>
-<div class="figure" id="id7">
+<div class="figure" id="id1">
 <img alt="Packet header mbuf" src="os/core_os/mbuf/pics/mbuf_fig1.png" />
 <p class="caption"><span class="caption-text">Packet header mbuf</span></p>
 </div>
@@ -328,49 +326,49 @@ <h2>Packet Header mbuf<a class="headerlink" href="#packet-header-mbuf" title="Pe
 <h2>Normal mbuf<a class="headerlink" href="#normal-mbuf" title="Permalink to this headline">?</a></h2>
 <p>Now let?s take a deeper dive into the mbuf structure. Figure 2
 illustrates a normal mbuf and breaks out the various fields in the
-<code class="docutils literal notranslate"><span class="pre">os_mbuf</span></code> structure.</p>
+c:type:<cite>os_mbuf</cite> structure.</p>
 <ul class="simple">
-<li>The <em>om_data</em> field is a pointer to where the data starts inside the
+<li>The <code class="xref c c-member docutils literal notranslate"><span class="pre">om_data</span></code> field is a pointer to where the data starts inside the
 data buffer. Typically, mbufs that are allocated from the mbuf pool
-(discussed later) have their om_data pointer set to the start of the
+(discussed later) have their <code class="xref c c-member docutils literal notranslate"><span class="pre">om_data</span></code> pointer set to the start of the
 data buffer but there are cases where this may not be desirable
 (added a protocol header to a packet, for example).</li>
-<li>The <em>om_flags</em> field is a set of flags used internally by the mbuf
+<li>The <code class="xref c c-member docutils literal notranslate"><span class="pre">om_flags</span></code> field is a set of flags used internally by the mbuf
 library. Currently, no flags have been defined.</li>
-<li>The <em>om_pkthdr_len</em> field is the total length of all packet headers
+<li>The <code class="xref c c-member docutils literal notranslate"><span class="pre">om_pkthdr_len</span></code> field is the total length of all packet headers
 in the mbuf. For normal mbufs this is set to 0 as there is no packet
 or user packet headers. For packet header mbufs, this would be set to
 the length of the packet header structure (16) plus the size of the
 user packet header (if any). Note that it is this field which
 differentiates packet header mbufs from normal mbufs (i.e. if
-<em>om_pkthdr_len</em> is zero, this is a normal mbuf; otherwise it is a
+<code class="xref c c-member docutils literal notranslate"><span class="pre">om_pkthdr_len</span></code> is zero, this is a normal mbuf; otherwise it is a
 packet header mbuf).</li>
-<li>The <em>om_len</em> field contains the amount of user data in the data
+<li>The <code class="xref c c-member docutils literal notranslate"><span class="pre">om_len</span></code> field contains the amount of user data in the data
 buffer. When initially allocated, this field is 0 as there is no user
 data in the mbuf.</li>
-<li>The <em>omp_pool</em> field is a pointer to the pool from which this mbuf
+<li>The <code class="xref c c-member docutils literal notranslate"><span class="pre">omp_pool</span></code> field is a pointer to the pool from which this mbuf
 has been allocated. This is used internally by the mbuf library.</li>
-<li>The <em>omp_next</em> field is a linked list element which is used to chain
+<li>The <code class="xref c c-member docutils literal notranslate"><span class="pre">omp_next</span></code> field is a linked list element which is used to chain
 mbufs.</li>
 </ul>
-<p>Figure 2 also shows a normal mbuf with actual values in the <code class="docutils literal notranslate"><span class="pre">os_mbuf</span></code>
+<p>Figure 2 also shows a normal mbuf with actual values in the <code class="xref c c-type docutils literal notranslate"><span class="pre">os_mbuf</span></code>
 structure. This mbuf starts at address 0x1000 and is 256 bytes in total
 length. In this example, the user has copied 33 bytes into the data
-buffer starting at address 0x1010 (this is where om_data points). Note
+buffer starting at address 0x1010 (this is where <code class="xref c c-member docutils literal notranslate"><span class="pre">om_data</span></code> points). Note
 that the packet header length in this mbuf is 0 as it is not a packet
 header mbuf.</p>
-<div class="figure" id="id8">
+<div class="figure" id="id2">
 <img alt="OS mbuf structure" src="os/core_os/mbuf/pics/mbuf_fig2.png" />
 <p class="caption"><span class="caption-text">OS mbuf structure</span></p>
 </div>
 <p>Figure 3 illustrates the packet header mbuf along with some chained
 mbufs (i.e a ?packet?). In this example, the user header structure is
 defined to be 8 bytes. Note that in figure 3 we show a number of
-different mbufs with varying <em>om_data</em> pointers and lengths since we
+different mbufs with varying <code class="xref c c-member docutils literal notranslate"><span class="pre">om_data</span></code> pointers and lengths since we
 want to show various examples of valid mbufs. For all the mbufs (both
 packet header and normal ones) the total length of the memory block is
 128 bytes.</p>
-<div class="figure" id="id9">
+<div class="figure" id="id3">
 <img alt="Packet" src="os/core_os/mbuf/pics/mbuf_fig3.png" />
 <p class="caption"><span class="caption-text">Packet</span></p>
 </div>
@@ -438,17 +436,48 @@ <h2>Create mbuf pool<a class="headerlink" href="#create-mbuf-pool" title="Permal
 </pre></div>
 </div>
 </div>
+<div class="section" id="msys">
+<h2>Msys<a class="headerlink" href="#msys" title="Permalink to this headline">?</a></h2>
+<p>Msys stands for ?system mbufs? and is a set of API built on top of the
+mbuf code. The basic idea behind msys is the following. The developer
+can create different size mbuf pools and register them with msys. The
+application then allocates mbufs using the msys API (as opposed to the
+mbuf API). The msys code will choose the mbuf pool with the smallest
+mbufs that can accommodate the requested size.</p>
+<p>Let us walk through an example where the user registers three mbuf pools
+with msys: one with 32 byte mbufs, one with 256 and one with 2048. If
+the user requests an mbuf with 10 bytes, the 32-byte mbuf pool is used.
+If the request is for 33 bytes the 256 byte mbuf pool is used. If an
+mbuf data size is requested that is larger than any of the pools (say,
+4000 bytes) the largest pool is used. While this behaviour may not be
+optimal in all cases that is the currently implemented behaviour. All
+this means is that the user is not guaranteed that a single mbuf can
+hold the requested data.</p>
+<p>The msys code will not allocate an mbuf from a larger pool if the chosen
+mbuf pool is empty. Similarly, the msys code will not chain together a
+number of smaller mbufs to accommodate the requested size. While this
+behaviour may change in future implementations the current code will
+simply return NULL. Using the above example, say the user requests 250
+bytes. The msys code chooses the appropriate pool (i.e. the 256 byte
+mbuf pool) and attempts to allocate an mbuf from that pool. If that pool
+is empty, NULL is returned even though the 32 and 2048 byte pools are
+not empty.</p>
+<p>Note that no added descriptions on how to use the msys API are presented
+here (other than in the API descriptions themselves) as the msys API is
+used in exactly the same manner as the mbuf API. The only difference is
+that mbuf pools are added to msys by calling <code class="docutils literal notranslate"><span class="pre">os_msys_register().</span></code></p>
+</div>
 <div class="section" id="using-mbufs">
 <h2>Using mbufs<a class="headerlink" href="#using-mbufs" title="Permalink to this headline">?</a></h2>
 <p>The following examples illustrate typical mbuf usage. There are two
-basic mbuf allocation API: <code class="docutils literal notranslate"><span class="pre">os_mbuf_get()</span></code> and
-<code class="docutils literal notranslate"><span class="pre">os_mbuf_get_pkthdr()</span></code>. The first API obtains a normal mbuf whereas
+basic mbuf allocation API: c:func:<cite>os_mbuf_get()</cite> and
+<a class="reference internal" href="#c.os_mbuf_get_pkthdr" title="os_mbuf_get_pkthdr"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_mbuf_get_pkthdr()</span></code></a>. The first API obtains a normal mbuf whereas
 the latter obtains a packet header mbuf. Typically, application
-developers use <code class="docutils literal notranslate"><span class="pre">os_mbuf_get_pkthdr()</span></code> and rarely, if ever, need to
-call <code class="docutils literal notranslate"><span class="pre">os_mbuf_get()</span></code> as the rest of the mbuf API (e.g.
-<code class="docutils literal notranslate"><span class="pre">os_mbuf_append()</span></code>, <code class="docutils literal notranslate"><span class="pre">os_mbuf_copyinto()</span></code>, etc.) typically deal with
-allocating and chaining mbufs. It is recommended to use the provided API
-to copy data into/out of mbuf chains and/or manipulate mbufs.</p>
+developers use <a class="reference internal" href="#c.os_mbuf_get_pkthdr" title="os_mbuf_get_pkthdr"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_mbuf_get_pkthdr()</span></code></a> and rarely, if ever, need to
+call <a class="reference internal" href="#c.os_mbuf_get" title="os_mbuf_get"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_mbuf_get()</span></code></a> as the rest of the mbuf API (e.g.
+<a class="reference internal" href="#c.os_mbuf_append" title="os_mbuf_append"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_mbuf_append()</span></code></a>, <a class="reference internal" href="#c.os_mbuf_copyinto" title="os_mbuf_copyinto"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_mbuf_copyinto()</span></code></a>, etc.) typically
+deal with allocating and chaining mbufs. It is recommended to use the
+provided API to copy data into/out of mbuf chains and/or manipulate mbufs.</p>
 <p>In <code class="docutils literal notranslate"><span class="pre">example1</span></code>, the developer creates a packet and then sends the
 packet to a networking interface. The code sample also provides an
 example of copying data out of an mbuf as well as use of the ?pullup?
@@ -550,225 +579,789 @@ <h2>Using mbufs<a class="headerlink" href="#using-mbufs" title="Permalink to thi
 </pre></div>
 </div>
 </div>
-<div class="section" id="data-structures">
-<h2>Data Structures<a class="headerlink" href="#data-structures" title="Permalink to this headline">?</a></h2>
-<div class="code c highlight-none notranslate"><div class="highlight"><pre><span></span>struct os_mbuf_pool {
-    uint16_t omp_databuf_len;
-    uint16_t omp_mbuf_count;
-    struct os_mempool *omp_pool;
-    STAILQ_ENTRY(os_mbuf_pool) omp_next;
-};
-</pre></div>
-</div>
-<table border="1" class="docutils">
-<colgroup>
-<col width="47%" />
-<col width="53%" />
-</colgroup>
-<thead valign="bottom">
-<tr class="row-odd"><th class="head"><strong>Element</strong></th>
-<th class="head"><a href="#id1"><span class="problematic" id="id2">**</span></a>Description*
-*</th>
-</tr>
-</thead>
-<tbody valign="top">
-<tr class="row-even"><td>omp_databuf
-_len</td>
-<td>The length, in
-bytes, of the
-?data buffer?
-of the mbuf.
-The data
-buffer of the
-mbuf is
-everything
-except the
-os_mbuf
-structure
-(which is
-present in all
-types of
-mbufs)</td>
-</tr>
-<tr class="row-odd"><td>omp_mbuf_c
-ount</td>
-<td>Total number
-of mbufs in
-the pool when
-allocated.
-This is NOT
-the number of
-free mbufs in
-the pool!</td>
-</tr>
-<tr class="row-even"><td>omp_pool</td>
-<td>The memory
-pool from
-which the
-mbufs are
-allocated</td>
-</tr>
-<tr class="row-odd"><td>omp_next</td>
-<td>This is a
-linked list
-pointer which
-chains memory
-pools. It is
-used by the
-system memory
-pool library</td>
-</tr>
-</tbody>
-</table>
-<div class="code c highlight-none notranslate"><div class="highlight"><pre><span></span>struct os_mbuf_pkthdr {
-    uint16_t omp_len;
-    uint16_t omp_flags;
-    STAILQ_ENTRY(os_mbuf_pkthdr) omp_next;
-};
-</pre></div>
+<div class="section" id="mqueue">
+<h2>Mqueue<a class="headerlink" href="#mqueue" title="Permalink to this headline">?</a></h2>
+<p>The mqueue construct allows a task to wake up when it receives data.
+Typically, this data is in the form of packets received over a network.
+A common networking stack operation is to put a packet on a queue and
+post an event to the task monitoring that queue. When the task handles
+the event, it processes each packet on the packet queue.</p>
 </div>
-<table border="1" class="docutils">
-<colgroup>
-<col width="47%" />
-<col width="53%" />
-</colgroup>
-<thead valign="bottom">
-<tr class="row-odd"><th class="head"><strong>Element</strong></th>
-<th class="head"><a href="#id3"><span class="problematic" id="id4">**</span></a>Description*
-*</th>
-</tr>
-</thead>
-<tbody valign="top">
-<tr class="row-even"><td>omp_len</td>
-<td>Length, in
-bytes, of the
-?packet?. This
-is the sum of
-the user data
-in all the
-mbufs chained
-to the packet
-header mbuf
-(including the
-packet header
-mbuf)</td>
-</tr>
-<tr class="row-odd"><td>omp_flags</td>
-<td>Packet header
-flags.</td>
-</tr>
-<tr class="row-even"><td>omp_next</td>
-<td>Linked list
-pointer to
-chain
-?packets?.
-This can be
-used to add
-mbuf chains to
-a queue or
-linked list
-and is there
-for
-convenience.</td>
-</tr>
-</tbody>
-</table>
-<div class="code c highlight-none notranslate"><div class="highlight"><pre><span></span>struct os_mbuf {
-    uint8_t *om_data;
-    uint8_t om_flags;
-    uint8_t om_pkthdr_len;
-    uint16_t om_len;
-    struct os_mbuf_pool *om_omp;
-    SLIST_ENTRY(os_mbuf) om_next;
-    uint8_t om_databuf[0];
-};
+<div class="section" id="using-mqueue">
+<h2>Using Mqueue<a class="headerlink" href="#using-mqueue" title="Permalink to this headline">?</a></h2>
+<p>The following code sample demonstrates how to use an mqueue. In this
+example:</p>
+<ul class="simple">
+<li>packets are put on a receive queue</li>
+<li>a task processes each packet on the queue (increments a receive
+counter)</li>
+</ul>
+<p>Not shown in the code example is a call <code class="docutils literal notranslate"><span class="pre">my_task_rx_data_func</span></code>.
+Presumably, some other code will call this API.</p>
+<div class="code c highlight-none notranslate"><div class="highlight"><pre><span></span>uint32_t pkts_rxd;
+struct os_mqueue rxpkt_q;
+struct os_eventq my_task_evq;
+
+/**
+ * Removes each packet from the receive queue and processes it.
+ */
+void
+process_rx_data_queue(void)
+{
+    struct os_mbuf *om;
+
+    while ((om = os_mqueue_get(&amp;rxpkt_q)) != NULL) {
+        ++pkts_rxd;
+        os_mbuf_free_chain(om);
+    }
+}
+
+/**
+ * Called when a packet is received.
+ */
+int
+my_task_rx_data_func(struct os_mbuf *om)
+{
+    int rc;
+
+    /* Enqueue the received packet and wake up the listening task. */
+    rc = os_mqueue_put(&amp;rxpkt_q, &amp;my_task_evq, om);
+    if (rc != 0) {
+        return -1;
+    }
+
+    return 0;
+}
+
+void
+my_task_handler(void *arg)
+{
+    struct os_event *ev;
+    struct os_callout_func *cf;
+    int rc;
+
+    /* Initialize eventq */
+    os_eventq_init(&amp;my_task_evq);
+
+    /* Initialize mqueue */
+    os_mqueue_init(&amp;rxpkt_q, NULL);
+
+    /* Process each event posted to our eventq.  When there are no events to
+     * process, sleep until one arrives.
+     */
+    while (1) {
+        os_eventq_run(&amp;my_task_evq);
+    }
+}
 </pre></div>
 </div>
-<table border="1" class="docutils">
-<colgroup>
-<col width="47%" />
-<col width="53%" />
-</colgroup>
-<thead valign="bottom">
-<tr class="row-odd"><th class="head"><strong>Element</strong></th>
-<th class="head"><a href="#id5"><span class="problematic" id="id6">**</span></a>Description*
-*</th>
-</tr>
-</thead>
-<tbody valign="top">
-<tr class="row-even"><td>om_data</td>
-<td>Pointer to
-start of user
-data in mbuf
-data buffer</td>
-</tr>
-<tr class="row-odd"><td>om_flags</td>
-<td>mbuf flags
-field.
-Currently all
-flags unused.</td>
-</tr>
-<tr class="row-even"><td>om_pkthdr_
-len</td>
-<td>The total
-length of all
-packet headers
-in the mbuf
-(mbuf packet
-header plus
-user packet
-header), in
-bytes</td>
-</tr>
-<tr class="row-odd"><td>om_len</td>
-<td>The length of
-the user data
-contained in
-this mbuf, in
-bytes</td>
-</tr>
-<tr class="row-even"><td>om_omp</td>
-<td>Memory pool
-pointer. This
-is the mbuf
-pool from
-which this
-mbuf was
-allocated.</td>
-</tr>
-<tr class="row-odd"><td>om_next</td>
-<td>Pointer to
-next mbuf in
-packet chain</td>
-</tr>
-<tr class="row-even"><td>om_databuf</td>
-<td>mbuf data
-buffer
-(accessor to
-start of mbuf
-data buffer).
-Note that the
-mbuf data
-buffer refers
-to the start
-of either the
-user data in
-normal mbufs
-or the start
-of the os mbuf
-packet header
-for packet
-header mbufs</td>
-</tr>
-</tbody>
-</table>
 </div>
 <div class="section" id="api">
 <h2>API<a class="headerlink" href="#api" title="Permalink to this headline">?</a></h2>
-<div class="admonition warning">
-<p class="first admonition-title">Warning</p>
-<p class="last">doxygengroup: Cannot find namespace ?OSMbuf? in doxygen xml output for project ?mynewt-core? from directory: mynewt-core-xml</p>
+<dl class="function">
+<dt id="c.os_mqueue_init">
+<span class="target" id="group___o_s_mbuf_1ga9763522ccbaeb6844dab335f6ee91342"></span>int <code class="descname">os_mqueue_init</code><span class="sig-paren">(</span>struct  os_mqueue  *<em>&nbsp;mq</em>, <a class="reference internal" href="../event_queue/event_queue.html#c.os_event_fn" title="os_event_fn">os_event_fn</a>  *<em>&nbsp;ev_cb</em>, void *<em>&nbsp;arg</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_mqueue_init" title="Permalink to this definition">?</a></dt>
+<dd><p>Initializes an mqueue. </p>
+<p>An mqueue is a queue of mbufs that ties to a particular task?s event queue. Mqueues form a helper API around a common paradigm: wait on an event queue until at least one packet is available, then process a queue of packets.</p>
+<p>When mbufs are available on the queue, an event OS_EVENT_T_MQUEUE_DATA will be posted to the task?s mbuf queue.</p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>0 on success, non-zero on failure. </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">mq</span></code>: The mqueue to initialize </li>
+<li><code class="docutils literal notranslate"><span class="pre">ev_cb</span></code>: The callback to associate with the mqeueue event. Typically, this callback pulls each packet off the mqueue and processes them. </li>
+<li><code class="docutils literal notranslate"><span class="pre">arg</span></code>: The argument to associate with the mqueue event.</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_mqueue_get">
+<span class="target" id="group___o_s_mbuf_1ga32306d7188418fdde8d0be121844b291"></span>struct os_mbuf* <code class="descname">os_mqueue_get</code><span class="sig-paren">(</span>struct  os_mqueue <em>&nbsp;*</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_mqueue_get" title="Permalink to this definition">?</a></dt>
+<dd><p>Remove and return a single mbuf from the mbuf queue. </p>
+<p>Does not block.</p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>The next mbuf in the queue, or NULL if queue has no mbufs. </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">mq</span></code>: The mbuf queue to pull an element off of.</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_mqueue_put">
+<span class="target" id="group___o_s_mbuf_1ga39221c77178f12af8bd4b2c24cad07b6"></span>int <code class="descname">os_mqueue_put</code><span class="sig-paren">(</span>struct  os_mqueue <em>&nbsp;*</em>, struct  os_eventq <em>&nbsp;*</em>, struct  os_mbuf <em>&nbsp;*</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_mqueue_put" title="Permalink to this definition">?</a></dt>
+<dd><p>Adds a packet (i.e. </p>
+<p>packet header mbuf) to an mqueue. The event associated with the mqueue gets posted to the specified eventq.</p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>0 on success, non-zero on failure. </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">mq</span></code>: The mbuf queue to append the mbuf to. </li>
+<li><code class="docutils literal notranslate"><span class="pre">evq</span></code>: The event queue to post an event to. </li>
+<li><code class="docutils literal notranslate"><span class="pre">m</span></code>: The mbuf to append to the mbuf queue.</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_msys_register">
+<span class="target" id="group___o_s_mbuf_1ga164e3f90cdee2692a85c249761ba001e"></span>int <code class="descname">os_msys_register</code><span class="sig-paren">(</span>struct  os_mbuf_pool <em>&nbsp;*</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_msys_register" title="Permalink to this definition">?</a></dt>
+<dd><p>MSYS is a system level mbuf registry. </p>
+<p>Allows the system to share packet buffers amongst the various networking stacks that can be running simultaeneously.</p>
+<p>Mbuf pools are created in the system initialization code, and then when a mbuf is allocated out of msys, it will try and find the best fit based upon estimated mbuf size.</p>
+<p><a class="reference internal" href="#group___o_s_mbuf_1ga164e3f90cdee2692a85c249761ba001e"><span class="std std-ref">os_msys_register()</span></a> registers a mbuf pool with MSYS, and allows MSYS to allocate mbufs out of it.</p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>0 on success, non-zero on failure </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">new_pool</span></code>: The pool to register with MSYS</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_msys_get">
+<span class="target" id="group___o_s_mbuf_1ga0e887615518be2d1fc721815dfd157c5"></span>struct os_mbuf* <code class="descname">os_msys_get</code><span class="sig-paren">(</span>uint16_t<em>&nbsp;dsize</em>, uint16_t<em>&nbsp;leadingspace</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_msys_get" title="Permalink to this definition">?</a></dt>
+<dd><p>Allocate a mbuf from msys. </p>
+<p>Based upon the data size requested, <a class="reference internal" href="#group___o_s_mbuf_1ga0e887615518be2d1fc721815dfd157c5"><span class="std std-ref">os_msys_get()</span></a> will choose the mbuf pool that has the best fit.</p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>A freshly allocated mbuf on success, NULL on failure. </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">dsize</span></code>: The estimated size of the data being stored in the mbuf </li>
+<li><code class="docutils literal notranslate"><span class="pre">leadingspace</span></code>: The amount of leadingspace to allocate in the mbuf</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_msys_reset">
+<span class="target" id="group___o_s_mbuf_1gaa984a74000da6f436912a99821baeb9a"></span>void <code class="descname">os_msys_reset</code><span class="sig-paren">(</span>void<span class="sig-paren">)</span><a class="headerlink" href="#c.os_msys_reset" title="Permalink to this definition">?</a></dt>
+<dd><p>De-registers all mbuf pools from msys. </p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_msys_get_pkthdr">
+<span class="target" id="group___o_s_mbuf_1ga841e0b4f77115ec9df4b5becc252f03e"></span>struct os_mbuf* <code class="descname">os_msys_get_pkthdr</code><span class="sig-paren">(</span>uint16_t<em>&nbsp;dsize</em>, uint16_t<em>&nbsp;user_hdr_len</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_msys_get_pkthdr" title="Permalink to this definition">?</a></dt>
+<dd><p>Allocate a packet header structure from the MSYS pool. </p>
+<p>See <a class="reference internal" href="#group___o_s_mbuf_1ga164e3f90cdee2692a85c249761ba001e"><span class="std std-ref">os_msys_register()</span></a> for a description of MSYS.</p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>A freshly allocated mbuf on success, NULL on failure. </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">dsize</span></code>: The estimated size of the data being stored in the mbuf </li>
+<li><code class="docutils literal notranslate"><span class="pre">user_hdr_len</span></code>: The length to allocate for the packet header structure</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_msys_count">
+<span class="target" id="group___o_s_mbuf_1ga82ba13b28a45ee54405dd7c4d6ea013b"></span>int <code class="descname">os_msys_count</code><span class="sig-paren">(</span>void<span class="sig-paren">)</span><a class="headerlink" href="#c.os_msys_count" title="Permalink to this definition">?</a></dt>
+<dd><p>Count the number of blocks in all the mbuf pools that are allocated. </p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>total number of blocks allocated in Msys </dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_msys_num_free">
+<span class="target" id="group___o_s_mbuf_1gadf2b97336a5ab02260a304188374d345"></span>int <code class="descname">os_msys_num_free</code><span class="sig-paren">(</span>void<span class="sig-paren">)</span><a class="headerlink" href="#c.os_msys_num_free" title="Permalink to this definition">?</a></dt>
+<dd><p>Return the number of free blocks in Msys. </p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>Number of free blocks available in Msys </dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_mbuf_pool_init">
+<span class="target" id="group___o_s_mbuf_1ga2895885c2f34a9582d2490558e782ff5"></span>int <code class="descname">os_mbuf_pool_init</code><span class="sig-paren">(</span>struct  os_mbuf_pool <em>&nbsp;*</em>, struct  os_mempool  *<em>&nbsp;mp</em>, uint16_t, uint16_t<span class="sig-paren">)</span><a class="headerlink" href="#c.os_mbuf_pool_init" title="Permalink to this definition">?</a></dt>
+<dd><p>Initialize a pool of mbufs. </p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>0 on success, error code on failure. </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">omp</span></code>: The mbuf pool to initialize </li>
+<li><code class="docutils literal notranslate"><span class="pre">mp</span></code>: The memory pool that will hold this mbuf pool </li>
+<li><code class="docutils literal notranslate"><span class="pre">buf_len</span></code>: The length of the buffer itself. </li>
+<li><code class="docutils literal notranslate"><span class="pre">nbufs</span></code>: The number of buffers in the pool</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_mbuf_get">
+<span class="target" id="group___o_s_mbuf_1gabf3bb711c79f3435c1da86f533e50296"></span>struct os_mbuf* <code class="descname">os_mbuf_get</code><span class="sig-paren">(</span>struct  os_mbuf_pool  *<em>&nbsp;omp</em>, uint16_t<span class="sig-paren">)</span><a class="headerlink" href="#c.os_mbuf_get" title="Permalink to this definition">?</a></dt>
+<dd><p>Get an mbuf from the mbuf pool. </p>
+<p>The mbuf is allocated, and initialized prior to being returned.</p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>An initialized mbuf on success, and NULL on failure. </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">omp</span></code>: The mbuf pool to return the packet from </li>
+<li><code class="docutils literal notranslate"><span class="pre">leadingspace</span></code>: The amount of leadingspace to put before the data section by default.</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_mbuf_get_pkthdr">
+<span class="target" id="group___o_s_mbuf_1ga717bd3c356c7555d5b93245d6e0e1b47"></span>struct os_mbuf* <code class="descname">os_mbuf_get_pkthdr</code><span class="sig-paren">(</span>struct  os_mbuf_pool  *<em>&nbsp;omp</em>, uint8_t<em>&nbsp;pkthdr_len</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_mbuf_get_pkthdr" title="Permalink to this definition">?</a></dt>
+<dd><p>Allocate a new packet header mbuf out of the <a class="reference internal" href="#structos__mbuf__pool"><span class="std std-ref">os_mbuf_pool</span></a>. </p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>A freshly allocated mbuf on success, NULL on failure. </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">omp</span></code>: The mbuf pool to allocate out of </li>
+<li><code class="docutils literal notranslate"><span class="pre">user_pkthdr_len</span></code>: The packet header length to reserve for the caller.</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_mbuf_dup">
+<span class="target" id="group___o_s_mbuf_1ga69b900ec646d9251fac4050ff49c3ab6"></span>struct os_mbuf* <code class="descname">os_mbuf_dup</code><span class="sig-paren">(</span>struct  os_mbuf  *<em>&nbsp;m</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_mbuf_dup" title="Permalink to this definition">?</a></dt>
+<dd><p>Duplicate a chain of mbufs. </p>
+<p>Return the start of the duplicated chain.</p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>A pointer to the new chain of mbufs </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">omp</span></code>: The mbuf pool to duplicate out of </li>
+<li><code class="docutils literal notranslate"><span class="pre">om</span></code>: The mbuf chain to duplicate</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_mbuf_off">
+<span class="target" id="group___o_s_mbuf_1gabbd3dd2b8880a323c70478f8988902af"></span>struct os_mbuf* <code class="descname">os_mbuf_off</code><span class="sig-paren">(</span>const struct  os_mbuf  *<em>&nbsp;om</em>, int<em>&nbsp;off</em>, uint16_t *<em>&nbsp;out_off</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_mbuf_off" title="Permalink to this definition">?</a></dt>
+<dd><p>Locates the specified absolute offset within an mbuf chain. </p>
+<p>The offset can be one past than the total length of the chain, but no greater.</p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>The mbuf containing the specified offset on success. NULL if the specified offset is out of bounds. </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">om</span></code>: The start of the mbuf chain to seek within. </li>
+<li><code class="docutils literal notranslate"><span class="pre">off</span></code>: The absolute address to find. </li>
+<li><code class="docutils literal notranslate"><span class="pre">out_off</span></code>: On success, this points to the relative offset within the returned mbuf.</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_mbuf_copydata">
+<span class="target" id="group___o_s_mbuf_1ga31d793aa91e9c7ae5b5002b10f95dd64"></span>int <code class="descname">os_mbuf_copydata</code><span class="sig-paren">(</span>const struct  os_mbuf  *<em>&nbsp;m</em>, int<em>&nbsp;off</em>, int<em>&nbsp;len</em>, void *<em>&nbsp;dst</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_mbuf_copydata" title="Permalink to this definition">?</a></dt>
+<dd></dd></dl>
+
+<dl class="function">
+<dt id="c.os_mbuf_append">
+<span class="target" id="group___o_s_mbuf_1ga672d3e6990c4d8fe60046ee6cde32ac1"></span>int <code class="descname">os_mbuf_append</code><span class="sig-paren">(</span>struct  os_mbuf  *<em>&nbsp;m</em>, const void<em>&nbsp;*</em>, uint16_t<span class="sig-paren">)</span><a class="headerlink" href="#c.os_mbuf_append" title="Permalink to this definition">?</a></dt>
+<dd><p>Append data onto a mbuf. </p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>0 on success, and an error code on failure </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">om</span></code>: The mbuf to append the data onto </li>
+<li><code class="docutils literal notranslate"><span class="pre">data</span></code>: The data to append onto the mbuf </li>
+<li><code class="docutils literal notranslate"><span class="pre">len</span></code>: The length of the data to append</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_mbuf_appendfrom">
+<span class="target" id="group___o_s_mbuf_1ga66da7f4e54d6dbf4dc2d7531b68d7db0"></span>int <code class="descname">os_mbuf_appendfrom</code><span class="sig-paren">(</span>struct  os_mbuf  *<em>&nbsp;dst</em>, const struct  os_mbuf  *<em>&nbsp;src</em>, uint16_t<em>&nbsp;src_off</em>, uint16_t<em>&nbsp;len</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_mbuf_appendfrom" title="Permalink to this definition">?</a></dt>
+<dd><p>Reads data from one mbuf and appends it to another. </p>
+<p>On error, the specified data range may be partially appended. Neither mbuf is required to contain an mbuf packet header.</p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>0 on success; OS_EINVAL if the specified range extends beyond the end of the source mbuf chain. </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">dst</span></code>: The mbuf to append to. </li>
+<li><code class="docutils literal notranslate"><span class="pre">src</span></code>: The mbuf to copy data from. </li>
+<li><code class="docutils literal notranslate"><span class="pre">src_off</span></code>: The absolute offset within the source mbuf chain to read from. </li>
+<li><code class="docutils literal notranslate"><span class="pre">len</span></code>: The number of bytes to append.</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_mbuf_free">
+<span class="target" id="group___o_s_mbuf_1ga2bcbfe183bd88962d78017cc51c59ed2"></span>int <code class="descname">os_mbuf_free</code><span class="sig-paren">(</span>struct  os_mbuf  *<em>&nbsp;mb</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_mbuf_free" title="Permalink to this definition">?</a></dt>
+<dd><p>Release a mbuf back to the pool. </p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>0 on success, -1 on failure </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">omp</span></code>: The Mbuf pool to release back to </li>
+<li><code class="docutils literal notranslate"><span class="pre">om</span></code>: The Mbuf to release back to the pool</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_mbuf_free_chain">
+<span class="target" id="group___o_s_mbuf_1ga66de6a0a042c35435547a1df9534cc3f"></span>int <code class="descname">os_mbuf_free_chain</code><span class="sig-paren">(</span>struct  os_mbuf  *<em>&nbsp;om</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_mbuf_free_chain" title="Permalink to this definition">?</a></dt>
+<dd><p>Free a chain of mbufs. </p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>0 on success, -1 on failure </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">omp</span></code>: The mbuf pool to free the chain of mbufs into </li>
+<li><code class="docutils literal notranslate"><span class="pre">om</span></code>: The starting mbuf of the chain to free back into the pool</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_mbuf_adj">
+<span class="target" id="group___o_s_mbuf_1gad1379ba25e8dc203a84ad6fc21f2880e"></span>void <code class="descname">os_mbuf_adj</code><span class="sig-paren">(</span>struct  os_mbuf  *<em>&nbsp;mp</em>, int<em>&nbsp;req_len</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_mbuf_adj" title="Permalink to this definition">?</a></dt>
+<dd><p>Adjust the length of a mbuf, trimming either from the head or the tail of the mbuf. </p>
+<p><dl class="docutils">
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">mp</span></code>: The mbuf chain to adjust </li>
+<li><code class="docutils literal notranslate"><span class="pre">req_len</span></code>: The length to trim from the mbuf. If positive, trims from the head of the mbuf, if negative, trims from the tail of the mbuf. </li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_mbuf_cmpf">
+<span class="target" id="group___o_s_mbuf_1gac5d238e8abd1a459c2daf8fe814e13d4"></span>int <code class="descname">os_mbuf_cmpf</code><span class="sig-paren">(</span>const struct  os_mbuf  *<em>&nbsp;om</em>, int<em>&nbsp;off</em>, const void *<em>&nbsp;data</em>, int<em>&nbsp;len</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_mbuf_cmpf" title="Permalink to this definition">?</a></dt>
+<dd><p>Performs a memory compare of the specified region of an mbuf chain against a flat buffer. </p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>0 if both memory regions are identical; A memcmp return code if there is a mismatch; INT_MAX if the mbuf is too short. </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">om</span></code>: The start of the mbuf chain to compare. </li>
+<li><code class="docutils literal notranslate"><span class="pre">off</span></code>: The offset within the mbuf chain to start the comparison. </li>
+<li><code class="docutils literal notranslate"><span class="pre">data</span></code>: The flat buffer to compare. </li>
+<li><code class="docutils literal notranslate"><span class="pre">len</span></code>: The length of the flat buffer.</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_mbuf_cmpm">
+<span class="target" id="group___o_s_mbuf_1ga11d6f4ce57b2c5c7b619831689f519f1"></span>int <code class="descname">os_mbuf_cmpm</code><span class="sig-paren">(</span>const struct  os_mbuf  *<em>&nbsp;om1</em>, uint16_t<em>&nbsp;offset1</em>, const struct  os_mbuf  *<em>&nbsp;om2</em>, uint16_t<em>&nbsp;offset2</em>, uint16_t<em>&nbsp;len</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_mbuf_cmpm" title="Permalink to this definition">?</a></dt>
+<dd><p>Compares the contents of two mbuf chains. </p>
+<p>The ranges of the two chains to be compared are specified via the two offset parameters and the len parameter. Neither mbuf chain is required to contain a packet header.</p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>0 if both mbuf segments are identical; A memcmp() return code if the segment contents differ; INT_MAX if a specified range extends beyond the end of its corresponding mbuf chain. </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">om1</span></code>: The first mbuf chain to compare. </li>
+<li><code class="docutils literal notranslate"><span class="pre">offset1</span></code>: The absolute offset within om1 at which to start the comparison. </li>
+<li><code class="docutils literal notranslate"><span class="pre">om2</span></code>: The second mbuf chain to compare. </li>
+<li><code class="docutils literal notranslate"><span class="pre">offset2</span></code>: The absolute offset within om2 at which to start the comparison. </li>
+<li><code class="docutils literal notranslate"><span class="pre">len</span></code>: The number of bytes to compare.</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_mbuf_prepend">
+<span class="target" id="group___o_s_mbuf_1gac16c27c68f35e4647823ae020411763f"></span>struct os_mbuf* <code class="descname">os_mbuf_prepend</code><span class="sig-paren">(</span>struct  os_mbuf  *<em>&nbsp;om</em>, int<em>&nbsp;len</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_mbuf_prepend" title="Permalink to this definition">?</a></dt>
+<dd><p>Increases the length of an mbuf chain by adding data to the front. </p>
+<p>If there is insufficient room in the leading mbuf, additional mbufs are allocated and prepended as necessary. If this function fails to allocate an mbuf, the entire chain is freed.</p>
+<p>The specified mbuf chain does not need to contain a packet header.</p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>The new head of the chain on success; NULL on failure. </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">omp</span></code>: The mbuf pool to allocate from. </li>
+<li><code class="docutils literal notranslate"><span class="pre">om</span></code>: The head of the mbuf chain. </li>
+<li><code class="docutils literal notranslate"><span class="pre">len</span></code>: The number of bytes to prepend.</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_mbuf_prepend_pullup">
+<span class="target" id="group___o_s_mbuf_1gac6e76dec13d44abd6032eb293aa1b63a"></span>struct os_mbuf* <code class="descname">os_mbuf_prepend_pullup</code><span class="sig-paren">(</span>struct  os_mbuf  *<em>&nbsp;om</em>, uint16_t<em>&nbsp;len</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_mbuf_prepend_pullup" title="Permalink to this definition">?</a></dt>
+<dd><p>Prepends a chunk of empty data to the specified mbuf chain and ensures the chunk is contiguous. </p>
+<p>If either operation fails, the specified mbuf chain is freed and NULL is returned.</p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>The modified mbuf on success; NULL on failure (and the mbuf chain is freed). </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">om</span></code>: The mbuf chain to prepend to. </li>
+<li><code class="docutils literal notranslate"><span class="pre">len</span></code>: The number of bytes to prepend and pullup.</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_mbuf_copyinto">
+<span class="target" id="group___o_s_mbuf_1ga5e87037857c05e8a9379bb2889947854"></span>int <code class="descname">os_mbuf_copyinto</code><span class="sig-paren">(</span>struct  os_mbuf  *<em>&nbsp;om</em>, int<em>&nbsp;off</em>, const void *<em>&nbsp;src</em>, int<em>&nbsp;len</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_mbuf_copyinto" title="Permalink to this definition">?</a></dt>
+<dd><p>Copies the contents of a flat buffer into an mbuf chain, starting at the specified destination offset. </p>
+<p>If the mbuf is too small for the source data, it is extended as necessary. If the destination mbuf contains a packet header, the header length is updated.</p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>0 on success; nonzero on failure. </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">omp</span></code>: The mbuf pool to allocate from. </li>
+<li><code class="docutils literal notranslate"><span class="pre">om</span></code>: The mbuf chain to copy into. </li>
+<li><code class="docutils literal notranslate"><span class="pre">off</span></code>: The offset within the chain to copy to. </li>
+<li><code class="docutils literal notranslate"><span class="pre">src</span></code>: The source buffer to copy from. </li>
+<li><code class="docutils literal notranslate"><span class="pre">len</span></code>: The number of bytes to copy.</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_mbuf_concat">
+<span class="target" id="group___o_s_mbuf_1ga65ab8ccc2730629ca0dd8c5190575213"></span>void <code class="descname">os_mbuf_concat</code><span class="sig-paren">(</span>struct  os_mbuf  *<em>&nbsp;first</em>, struct  os_mbuf  *<em>&nbsp;second</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_mbuf_concat" title="Permalink to this definition">?</a></dt>
+<dd><p>Attaches a second mbuf chain onto the end of the first. </p>
+<p>If the first chain contains a packet header, the header?s length is updated. If the second chain has a packet header, its header is cleared.</p>
+<p><dl class="docutils">
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">first</span></code>: The mbuf chain being attached to. </li>
+<li><code class="docutils literal notranslate"><span class="pre">second</span></code>: The mbuf chain that gets attached. </li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_mbuf_extend">
+<span class="target" id="group___o_s_mbuf_1ga67d81c50479c67444fd1a9449d4241ed"></span>void* <code class="descname">os_mbuf_extend</code><span class="sig-paren">(</span>struct  os_mbuf  *<em>&nbsp;om</em>, uint16_t<em>&nbsp;len</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_mbuf_extend" title="Permalink to this definition">?</a></dt>
+<dd><p>Increases the length of an mbuf chain by the specified amount. </p>
+<p>If there is not sufficient room in the last buffer, a new buffer is allocated and appended to the chain. It is an error to request more data than can fit in a single buffer.</p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>A pointer to the new data on success; NULL on failure. </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">omp</span></code>: </li>
+<li><code class="docutils literal notranslate"><span class="pre">om</span></code>: The head of the chain to extend. </li>
+<li><code class="docutils literal notranslate"><span class="pre">len</span></code>: The number of bytes to extend by.</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_mbuf_pullup">
+<span class="target" id="group___o_s_mbuf_1ga3afad6750be6e7647ff0a19112ea36f7"></span>struct os_mbuf* <code class="descname">os_mbuf_pullup</code><span class="sig-paren">(</span>struct  os_mbuf  *<em>&nbsp;om</em>, uint16_t<em>&nbsp;len</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_mbuf_pullup" title="Permalink to this definition">?</a></dt>
+<dd><p>Rearrange a mbuf chain so that len bytes are contiguous, and in the data area of an mbuf (so that <a class="reference internal" href="#group___o_s_mbuf_1ga4bf84d7b323b20131da17c8bfed65674"><span class="std std-ref">OS_MBUF_DATA()</span></a> will work on a structure of size len.) Returns the resulting mbuf chain on success, free?s it and returns NULL on failure. </p>
+<p>If there is room, it will add up to ?max_protohdr - len? extra bytes to the contiguous region, in an attempt to avoid being called next time.</p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>The contiguous mbuf chain on success, NULL on failure. </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">omp</span></code>: The mbuf pool to take the mbufs out of </li>
+<li><code class="docutils literal notranslate"><span class="pre">om</span></code>: The mbuf chain to make contiguous </li>
+<li><code class="docutils literal notranslate"><span class="pre">len</span></code>: The number of bytes in the chain to make contiguous</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_mbuf_trim_front">
+<span class="target" id="group___o_s_mbuf_1ga76d87394f85361c8a72d7ec0f0416bd6"></span>struct os_mbuf* <code class="descname">os_mbuf_trim_front</code><span class="sig-paren">(</span>struct  os_mbuf  *<em>&nbsp;om</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_mbuf_trim_front" title="Permalink to this definition">?</a></dt>
+<dd><p>Removes and frees empty mbufs from the front of a chain. </p>
+<p>If the chain contains a packet header, it is preserved.</p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>The head of the trimmed mbuf chain. </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">om</span></code>: The mbuf chain to trim.</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="define">
+<dt id="c.OS_MBUF_F_MASK">
+<span class="target" id="group___o_s_mbuf_1gafc8811efeca97f3c412416bb01ed746e"></span><code class="descname">OS_MBUF_F_MASK</code><span class="sig-paren">(</span>__n<span class="sig-paren">)</span><a class="headerlink" href="#c.OS_MBUF_F_MASK" title="Permalink to this definition">?</a></dt>
+<dd></dd></dl>
+
+<dl class="define">
+<dt id="c.OS_MBUF_IS_PKTHDR">
+<span class="target" id="group___o_s_mbuf_1ga44478552b659f6780f750528b8345577"></span><code class="descname">OS_MBUF_IS_PKTHDR</code><span class="sig-paren">(</span>__om<span class="sig-paren">)</span><a class="headerlink" href="#c.OS_MBUF_IS_PKTHDR" title="Permalink to this definition">?</a></dt>
+<dd></dd></dl>
+
+<dl class="define">
+<dt id="c.OS_MBUF_PKTHDR">
+<span class="target" id="group___o_s_mbuf_1ga6cac59130516e8c8bc98f27bb1d18a9e"></span><code class="descname">OS_MBUF_PKTHDR</code><span class="sig-paren">(</span>__om<span class="sig-paren">)</span><a class="headerlink" href="#c.OS_MBUF_PKTHDR" title="Permalink to this definition">?</a></dt>
+<dd><p>Get a packet header pointer given an mbuf pointer. </p>
+</dd></dl>
+
+<dl class="define">
+<dt id="c.OS_MBUF_PKTHDR_TO_MBUF">
+<span class="target" id="group___o_s_mbuf_1ga753a06f73d0b8dc916969e9ae490c0ce"></span><code class="descname">OS_MBUF_PKTHDR_TO_MBUF</code><span class="sig-paren">(</span>__hdr<span class="sig-paren">)</span><a class="headerlink" href="#c.OS_MBUF_PKTHDR_TO_MBUF" title="Permalink to this definition">?</a></dt>
+<dd><p>Given a mbuf packet header pointer, return a pointer to the mbuf. </p>
+</dd></dl>
+
+<dl class="define">
+<dt id="c.OS_MBUF_PKTLEN">
+<span class="target" id="group___o_s_mbuf_1gae286e94341ed58ac3be7b7a3cd0f1c25"></span><code class="descname">OS_MBUF_PKTLEN</code><span class="sig-paren">(</span>__om<span class="sig-paren">)</span><a class="headerlink" href="#c.OS_MBUF_PKTLEN" title="Permalink to this definition">?</a></dt>
+<dd><p>Gets the length of an entire mbuf chain. </p>
+<p>The specified mbuf must have a packet header. </p>
+</dd></dl>
+
+<dl class="define">
+<dt id="c.OS_MBUF_DATA">
+<span class="target" id="group___o_s_mbuf_1ga4bf84d7b323b20131da17c8bfed65674"></span><code class="descname">OS_MBUF_DATA</code><span class="sig-paren">(</span>__om, __type<span class="sig-paren">)</span><a class="headerlink" href="#c.OS_MBUF_DATA" title="Permalink to this definition">?</a></dt>
+<dd><p>Access the data of a mbuf, and cast it to type. </p>
+<p><dl class="docutils">
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">__om</span></code>: The mbuf to access, and cast </li>
+<li><code class="docutils literal notranslate"><span class="pre">__type</span></code>: The type to cast it to </li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="define">
+<dt id="c.OS_MBUF_USRHDR">
+<span class="target" id="group___o_s_mbuf_1ga6a70c33b992b2c96ddbbea7a8e13ac4c"></span><code class="descname">OS_MBUF_USRHDR</code><span class="sig-paren">(</span>om<span class="sig-paren">)</span><a class="headerlink" href="#c.OS_MBUF_USRHDR" title="Permalink to this definition">?</a></dt>
+<dd><p>Access the ?user header? in the head of an mbuf chain. </p>
+<p><dl class="docutils">
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">om</span></code>: Pointer to the head of an mbuf chain. </li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="define">
+<dt id="c.OS_MBUF_USRHDR_LEN">
+<span class="target" id="group___o_s_mbuf_1gab603a13e3de7d579605bce345e3c5101"></span><code class="descname">OS_MBUF_USRHDR_LEN</code><span class="sig-paren">(</span>om<span class="sig-paren">)</span><a class="headerlink" href="#c.OS_MBUF_USRHDR_LEN" title="Permalink to this definition">?</a></dt>
+<dd><p>Retrieves the length of the user header in an mbuf. </p>
+<p><dl class="docutils">
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">om</span></code>: Pointer to the mbuf to query. </li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="define">
+<dt id="c.OS_MBUF_LEADINGSPACE">
+<span class="target" id="group___o_s_mbuf_1gafa645aa091541bcc590e1f7091a35a7d"></span><code class="descname">OS_MBUF_LEADINGSPACE</code><span class="sig-paren">(</span>__om<span class="sig-paren">)</span><a class="headerlink" href="#c.OS_MBUF_LEADINGSPACE" title="Permalink to this definition">?</a></dt>
+<dd><p>Returns the leading space (space at the beginning) of the mbuf. </p>
+<p>Works on both packet header, and regular mbufs, as it accounts for the additional space allocated to the packet header.</p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>Amount of leading space available in the mbuf </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">__omp</span></code>: Is the mbuf pool (which contains packet header length.) </li>
+<li><code class="docutils literal notranslate"><span class="pre">__om</span></code>: Is the mbuf in that pool to get the leadingspace for</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="define">
+<dt id="c.OS_MBUF_TRAILINGSPACE">
+<span class="target" id="group___o_s_mbuf_1ga6bed008283a020a38886e68997b99239"></span><code class="descname">OS_MBUF_TRAILINGSPACE</code><span class="sig-paren">(</span>__om<span class="sig-paren">)</span><a class="headerlink" href="#c.OS_MBUF_TRAILINGSPACE" title="Permalink to this definition">?</a></dt>
+<dd><p>Returns the trailing space (space at the end) of the mbuf. </p>
+<p>Works on both packet header and regular mbufs.</p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>The amount of trailing space available in the mbuf </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">__omp</span></code>: The mbuf pool for this mbuf </li>
+<li><code class="docutils literal notranslate"><span class="pre">__om</span></code>: Is the mbuf in that pool to get trailing space for</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="class">
+<dt id="_CPPv312os_mbuf_pool">
+<span id="_CPPv212os_mbuf_pool"></span><span id="os_mbuf_pool"></span><span class="target" id="structos__mbuf__pool"></span><em class="property">struct </em><code class="descname">os_mbuf_pool</code><a class="headerlink" href="#_CPPv312os_mbuf_pool" title="Permalink to this definition">?</a><br /></dt>
+<dd><em>#include &lt;os_mbuf.h&gt;</em><p>A mbuf pool from which to allocate mbufs. </p>
+<p>This contains a pointer to the os mempool to allocate mbufs out of, the total number of elements in the pool, and the amount of ?user? data in a non-packet header mbuf. The total pool size, in bytes, should be: os_mbuf_count * (omp_databuf_len + sizeof(struct os_mbuf)) </p>
+<div class="breathe-sectiondef docutils container">
+<p class="breathe-sectiondef-title rubric">Public Members</p>
+<dl class="variable">
+<dt id="c.os_mbuf_pool::omp_databuf_len">
+<span class="target" id="structos__mbuf__pool_1a4ec5eeea1727efc7765dd95d60f5c1df"></span>uint16_t <code class="descname">omp_databuf_len</code><a class="headerlink" href="#c.os_mbuf_pool::omp_databuf_len" title="Permalink to this definition">?</a></dt>
+<dd><p>Total length of the databuf in each mbuf. </p>
+<p>This is the size of the mempool block, minus the mbuf header </p>
+</dd></dl>
+
+<dl class="variable">
+<dt id="c.os_mbuf_pool::omp_pool">
+<span class="target" id="structos__mbuf__pool_1a883d0c3aa305284ebd19bd3c62037430"></span>struct os_mempool* <code class="descname">omp_pool</code><a class="headerlink" href="#c.os_mbuf_pool::omp_pool" title="Permalink to this definition">?</a></dt>
+<dd><p>The memory pool which to allocate mbufs out of. </p>
+</dd></dl>
+
 </div>
+</dd></dl>
+
+<dl class="class">
+<dt id="_CPPv314os_mbuf_pkthdr">
+<span id="_CPPv214os_mbuf_pkthdr"></span><span id="os_mbuf_pkthdr"></span><span class="target" id="structos__mbuf__pkthdr"></span><em class="property">struct </em><code class="descname">os_mbuf_pkthdr</code><a class="headerlink" href="#_CPPv314os_mbuf_pkthdr" title="Permalink to this definition">?</a><br /></dt>
+<dd><em>#include &lt;os_mbuf.h&gt;</em><p>A packet header structure that preceeds the mbuf packet headers. </p>
+<div class="breathe-sectiondef docutils container">
+<p class="breathe-sectiondef-title rubric">Public Members</p>
+<dl class="variable">
+<dt id="c.os_mbuf_pkthdr::omp_len">
+<span class="target" id="structos__mbuf__pkthdr_1aeb48e54eaea9964c2cd4e856722def7f"></span>uint16_t <code class="descname">omp_len</code><a class="headerlink" href="#c.os_mbuf_pkthdr::omp_len" title="Permalink to this definition">?</a></dt>
+<dd><p>Overall length of the packet. </p>
+</dd></dl>
+
+<dl class="variable">
+<dt id="c.os_mbuf_pkthdr::omp_flags">
+<span class="target" id="structos__mbuf__pkthdr_1aee78ee1e9d30477e0253d9ed5245c36b"></span>uint16_t <code class="descname">omp_flags</code><a class="headerlink" href="#c.os_mbuf_pkthdr::omp_flags" title="Permalink to this definition">?</a></dt>
+<dd><p>Flags. </p>
+</dd></dl>
+
+</div>
+</dd></dl>
+
+<dl class="class">
+<dt id="_CPPv37os_mbuf">
+<span id="_CPPv27os_mbuf"></span><span id="os_mbuf"></span><span class="target" id="structos__mbuf"></span><em class="property">struct </em><code class="descname">os_mbuf</code><a class="headerlink" href="#_CPPv37os_mbuf" title="Permalink to this definition">?</a><br /></dt>
+<dd><em>#include &lt;os_mbuf.h&gt;</em><p>Chained memory buffer. </p>
+<div class="breathe-sectiondef docutils container">
+<p class="breathe-sectiondef-title rubric">Public Members</p>
+<dl class="variable">
+<dt id="c.os_mbuf::om_data">
+<span class="target" id="structos__mbuf_1a26c2267833d75b8af52f511c431e07de"></span>uint8_t* <code class="descname">om_data</code><a class="headerlink" href="#c.os_mbuf::om_data" title="Permalink to this definition">?</a></dt>
+<dd><p>Current pointer to data in the structure. </p>
+</dd></dl>
+
+<dl class="variable">
+<dt id="c.os_mbuf::om_flags">
+<span class="target" id="structos__mbuf_1a534559bde8149d283cf8571164a5fcfc"></span>uint8_t <code class="descname">om_flags</code><a class="headerlink" href="#c.os_mbuf::om_flags" title="Permalink to this definition">?</a></dt>
+<dd><p>Flags associated with this buffer, see OS_MBUF_F_* defintions. </p>
+</dd></dl>
+
+<dl class="variable">
+<dt id="c.os_mbuf::om_pkthdr_len">
+<span class="target" id="structos__mbuf_1a809d8377b268edeb774cdc37be654130"></span>uint8_t <code class="descname">om_pkthdr_len</code><a class="headerlink" href="#c.os_mbuf::om_pkthdr_len" title="Permalink to this definition">?</a></dt>
+<dd><p>Length of packet header. </p>
+</dd></dl>
+
+<dl class="variable">
+<dt id="c.os_mbuf::om_len">
+<span class="target" id="structos__mbuf_1a685a98624cf0d8ad353967e18eb3506a"></span>uint16_t <code class="descname">om_len</code><a class="headerlink" href="#c.os_mbuf::om_len" title="Permalink to this definition">?</a></dt>
+<dd><p>Length of data in this buffer. </p>
+</dd></dl>
+
+<dl class="variable">
+<dt id="c.os_mbuf::om_omp">
+<span class="target" id="structos__mbuf_1a06b4de9c818acdf09241b0cbe3d6a207"></span>struct os_mbuf_pool* <code class="descname">om_omp</code><a class="headerlink" href="#c.os_mbuf::om_omp" title="Permalink to this definition">?</a></dt>
+<dd><p>The mbuf pool this mbuf was allocated out of. </p>
+</dd></dl>
+
+<dl class="variable">
+<dt>
+<span class="target" id="structos__mbuf_1a3928b4bdc7b67b9bbb6ef8f1f3133b01"></span><code class="descname">uint8_t os_mbuf::om_databuf[0]</code></dt>
+<dd><p>Pointer to the beginning of the data, after this buffer. </p>
+</dd></dl>
+
+</div>
+</dd></dl>
+
+<dl class="class">
+<dt id="_CPPv39os_mqueue">
+<span id="_CPPv29os_mqueue"></span><span id="os_mqueue"></span><span class="target" id="structos__mqueue"></span><em class="property">struct </em><code class="descname">os_mqueue</code><a class="headerlink" href="#_CPPv39os_mqueue" title="Permalink to this definition">?</a><br /></dt>
+<dd><em>#include &lt;os_mbuf.h&gt;</em><p>Structure representing a queue of mbufs. </p>
+<div class="breathe-sectiondef docutils container">
+<p class="breathe-sectiondef-title rubric">Public Members</p>
+<dl class="variable">
+<dt id="c.os_mqueue::mq_ev">
+<span class="target" id="structos__mqueue_1a30ed7b555fcb87d7829dd6a1f34540db"></span>struct os_event <code class="descname">mq_ev</code><a class="headerlink" href="#c.os_mqueue::mq_ev" title="Permalink to this definition">?</a></dt>
+<dd><p>Event to post when new buffers are available on the queue. </p>
+</dd></dl>
+
+</div>
+</dd></dl>
+
 </div>
 </div>
 
@@ -778,10 +1371,10 @@ <h2>API<a class="headerlink" href="#api" title="Permalink to this headline">?</
                   
     <div class="rst-footer-buttons row" role="navigation" aria-label="footer navigation">
       
-        <a href="../msys/msys.html" class="btn btn-neutral float-right" title="Msys" accesskey="n">Next: Msys <span class="fa fa-arrow-circle-right"></span></a>
+        <a href="../cputime/os_cputime.html" class="btn btn-neutral float-right" title="CPU Time" accesskey="n">Next: CPU Time <span class="fa fa-arrow-circle-right"></span></a>
       
       
-        <a href="../heap/heap.html" class="btn btn-neutral" title="Heap" accesskey="p"><span class="fa fa-arrow-circle-left"></span> Previous: Heap</a>
+        <a href="../memory_pool/memory_pool.html" class="btn btn-neutral" title="Memory Pools" accesskey="p"><span class="fa fa-arrow-circle-left"></span> Previous: Memory Pools</a>
       
     </div>
 
diff --git a/develop/os/core_os/memory_pool/memory_pool.html b/develop/os/core_os/memory_pool/memory_pool.html
index b439217d1..1d4903a8d 100644
--- a/develop/os/core_os/memory_pool/memory_pool.html
+++ b/develop/os/core_os/memory_pool/memory_pool.html
@@ -41,9 +41,9 @@
                 href="../../../genindex.html"/>
           <link rel="search" title="Search" href="../../../search.html"/>
       <link rel="top" title="Apache Mynewt 1.3.0 documentation" href="../../../index.html"/>
-          <link rel="up" title="Mynewt Core OS" href="../mynewt_os.html"/>
-          <link rel="next" title="Heap" href="../heap/heap.html"/>
-          <link rel="prev" title="Mutex" href="../mutex/mutex.html"/> 
+          <link rel="up" title="Apache Mynewt Operating System Kernel" href="../mynewt_os.html"/>
+          <link rel="next" title="Mbufs" href="../mbuf/mbuf.html"/>
+          <link rel="prev" title="Heap" href="../heap/heap.html"/> 
 
     
     <script src="../../../_static/js/modernizr.min.js"></script>
@@ -156,7 +156,7 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
     
       <a href="../../os_user_guide.html">OS User Guide</a> /
     
-      <a href="../mynewt_os.html">Mynewt Core OS</a> /
+      <a href="../mynewt_os.html">Apache Mynewt Operating System Kernel</a> /
     
     Memory Pools
     
@@ -224,27 +224,25 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
 <li class="toctree-l1"><a class="reference internal" href="../../../concepts.html">Concepts</a></li>
 <li class="toctree-l1"><a class="reference internal" href="../../../tutorials/tutorials.html">Tutorials</a></li>
 <li class="toctree-l1 current"><a class="reference internal" href="../../os_user_guide.html">OS User Guide</a><ul class="current">
-<li class="toctree-l2 current"><a class="reference internal" href="../mynewt_os.html">OS Core</a><ul class="current">
+<li class="toctree-l2 current"><a class="reference internal" href="../mynewt_os.html">Kernel</a><ul class="current">
 <li class="toctree-l3"><a class="reference internal" href="../context_switch/context_switch.html">Scheduler</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../cputime/os_cputime.html">CPU Time</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../time/os_time.html">OS Time</a></li>
 <li class="toctree-l3"><a class="reference internal" href="../task/task.html">Task</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../event_queue/event_queue.html">Event Queues</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../semaphore/semaphore.html">Semaphore</a></li>
 <li class="toctree-l3"><a class="reference internal" href="../mutex/mutex.html">Mutex</a></li>
-<li class="toctree-l3 current"><a class="current reference internal" href="#">Memory Pools</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../semaphore/semaphore.html">Semaphore</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../event_queue/event_queue.html">Event Queues</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../callout/callout.html">Callout</a></li>
 <li class="toctree-l3"><a class="reference internal" href="../heap/heap.html">Heap</a></li>
+<li class="toctree-l3 current"><a class="current reference internal" href="#">Memory Pools</a></li>
 <li class="toctree-l3"><a class="reference internal" href="../mbuf/mbuf.html">Mbufs</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../msys/msys.html">Msys</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../mqueue/mqueue.html">Mqueue</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../cputime/os_cputime.html">CPU Time</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../time/os_time.html">OS Time</a></li>
 <li class="toctree-l3"><a class="reference internal" href="../sanity/sanity.html">Sanity</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../callout/callout.html">Callout</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../API.html">API</a></li>
 </ul>
 </li>
-<li class="toctree-l2"><a class="reference internal" href="../porting/port_os.html">Porting Mynewt OS</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../../modules/hal/hal.html">Hardware Abstraction</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../porting/port_os.html">Porting Guide</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../../modules/sysinitconfig/sysinitconfig.html">System Configuration</a></li>
 <li class="toctree-l2"><a class="reference internal" href="../../modules/console/console.html">Console</a></li>
-<li class="toctree-l2"><a class="reference internal" href="../../modules/sysinitconfig/sysinitconfig.html">System Configuration and Initialization</a></li>
 </ul>
 </li>
 <li class="toctree-l1"><a class="reference internal" href="../../../network/ble/ble_intro.html">BLE User Guide</a></li>
@@ -301,22 +299,22 @@ <h2>Description<a class="headerlink" href="#description" title="Permalink to thi
 determining the amount of memory required for the memory pool, simply
 multiplying the number of blocks by the size of each block is not
 sufficient as the OS may have alignment requirements. The alignment size
-definition is named <code class="docutils literal notranslate"><span class="pre">OS_ALIGNMENT</span></code> and can be found in os_arch.h as
+definition is named <code class="xref c c-macro docutils literal notranslate"><span class="pre">OS_ALIGNMENT</span></code> and can be found in os_arch.h as
 it is architecture specific. The memory block alignment is usually for
 efficiency but may be due to other reasons. Generally, blocks are
 aligned on 32-bit boundaries. Note that memory blocks must also be of
 sufficient size to hold a list pointer as this is needed to chain memory
 blocks on the free list.</p>
 <p>In order to simplify this for the user two macros have been provided:
-<code class="docutils literal notranslate"><span class="pre">OS_MEMPOOL_BYTES(n,</span> <span class="pre">blksize)</span></code> and <code class="docutils literal notranslate"><span class="pre">OS_MEMPOOL_SIZE(n,</span> <span class="pre">blksize)</span></code>.
+c:macro:<cite>OS_MEMPOOL_BYTES(n, blksize)</cite> and <code class="xref c c-macro docutils literal notranslate"><span class="pre">OS_MEMPOOL_SIZE(n,</span> <span class="pre">blksize)</span></code>.
 The first macro returns the number of bytes needed for the memory pool
-while the second returns the number of <code class="docutils literal notranslate"><span class="pre">os_membuf_t</span></code> elements required
-by the memory pool. The <code class="docutils literal notranslate"><span class="pre">os_membuf_t</span></code> type is used to guarantee that
+while the second returns the number of <code class="xref c c-type docutils literal notranslate"><span class="pre">os_membuf_t`</span></code> elements required
+by the memory pool. The <a class="reference internal" href="#c.os_membuf_t" title="os_membuf_t"><code class="xref c c-type docutils literal notranslate"><span class="pre">os_membuf_t</span></code></a> type is used to guarantee that
 the memory buffer used by the memory pool is aligned on the correct
 boundary.</p>
 <p>Here are some examples. Note that if a custom malloc implementation is
 used it must guarantee that the memory buffer used by the pool is
-allocated on the correct boundary (i.e. OS_ALIGNMENT).</p>
+allocated on the correct boundary (i.e. <code class="xref c c-macro docutils literal notranslate"><span class="pre">OS_ALIGNMENT</span></code>).</p>
 <div class="code c highlight-none notranslate"><div class="highlight"><pre><span></span>void *my_memory_buffer;
 my_memory_buffer = malloc(OS_MEMPOOL_BYTES(NUM_BLOCKS, BLOCK_SIZE));
 </pre></div>
@@ -326,125 +324,305 @@ <h2>Description<a class="headerlink" href="#description" title="Permalink to thi
 </div>
 <p>Now that the memory pool has been defined as well as the memory
 required for the memory blocks which make up the pool the user needs to
-initialize the memory pool by calling <code class="docutils literal notranslate"><span class="pre">os_mempool_init</span></code>.</p>
+initialize the memory pool by calling <code class="xref c c-func docutils literal notranslate"><span class="pre">os_mempool_init`()</span></code>.</p>
 <div class="code c highlight-none notranslate"><div class="highlight"><pre><span></span>os_mempool_init(&amp;my_pool, NUM_BLOCKS, BLOCK_SIZE, my_memory_buffer,
                          &quot;MyPool&quot;);
 </pre></div>
 </div>
 <p>Once the memory pool has been initialized the developer can allocate
-memory blocks from the pool by calling <code class="docutils literal notranslate"><span class="pre">os_memblock_get</span></code>. When the
+memory blocks from the pool by calling <a class="reference internal" href="#c.os_memblock_get" title="os_memblock_get"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_memblock_get()</span></code></a>. When the
 memory block is no longer needed the memory can be freed by calling
-<code class="docutils literal notranslate"><span class="pre">os_memblock_put</span></code>.</p>
-</div>
-<div class="section" id="data-structures">
-<h2>Data structures<a class="headerlink" href="#data-structures" title="Permalink to this headline">?</a></h2>
-<div class="code c highlight-none notranslate"><div class="highlight"><pre><span></span>struct os_mempool {
-    int mp_block_size;
-    int mp_num_blocks;
-    int mp_num_free;
-    int mp_min_free;
-    uint32_t mp_membuf_addr;
-    STAILQ_ENTRY(os_mempool) mp_list;
-    SLIST_HEAD(,os_memblock);
-    char *name;
-};
-
-struct os_mempool_info {
-    int omi_block_size;
-    int omi_num_blocks;
-    int omi_num_free;
-    int omi_min_free;
-    char omi_name[OS_MEMPOOL_INFO_NAME_LEN];
-};
-</pre></div>
-</div>
-<table border="1" class="docutils">
-<colgroup>
-<col width="47%" />
-<col width="53%" />
-</colgroup>
-<thead valign="bottom">
-<tr class="row-odd"><th class="head"><strong>Element</strong></th>
-<th class="head"><a href="#id1"><span class="problematic" id="id2">**</span></a>Description*
-*</th>
-</tr>
-</thead>
-<tbody valign="top">
-<tr class="row-even"><td>mp_block_s
-ize</td>
-<td>Size of the
-memory blocks,
-in bytes. This
-is not the
-actual number
-of bytes used
-by each block;
-it is the
-requested size
-of each block.
-The actual
-memory block
-size will be
-aligned to
-OS_ALIGNMENT
-bytes</td>
-</tr>
-<tr class="row-odd"><td>mp_num_blo
-cks</td>
-<td>Number of
-memory blocks
-in the pool</td>
-</tr>
-<tr class="row-even"><td>mp_num_fre
-e</td>
-<td>Number of free
-blocks left</td>
-</tr>
-<tr class="row-odd"><td>mp_min_fre
-e</td>
-<td>Lowest number
-of free blocks
-seen</td>
-</tr>
-<tr class="row-even"><td>mp_membuf_
-addr</td>
-<td>The address of
-the memory
-block. This is
-used to check
-that a valid
-memory block
-is being
-freed.</td>
-</tr>
-<tr class="row-odd"><td>mp_list</td>
-<td>List pointer
-to chain
-memory pools
-so they can be
-displayed by
-newt tools</td>
-</tr>
-<tr class="row-even"><td>SLIST_HEAD(
-,os_membloc
-k)</td>
-<td>List pointer
-to chain free
-memory blocks</td>
-</tr>
-<tr class="row-odd"><td>name</td>
-<td>Name for the
-memory block</td>
-</tr>
-</tbody>
-</table>
+<a class="reference internal" href="#c.os_memblock_put" title="os_memblock_put"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_memblock_put()</span></code></a>.</p>
 </div>
 <div class="section" id="api">
 <h2>API<a class="headerlink" href="#api" title="Permalink to this headline">?</a></h2>
-<div class="admonition warning">
-<p class="first admonition-title">Warning</p>
-<p class="last">doxygengroup: Cannot find namespace ?OSMempool? in doxygen xml output for project ?mynewt-core? from directory: mynewt-core-xml</p>
+<dl class="typedef">
+<dt id="c.os_mempool_put_fn">
+<span class="target" id="group___o_s_mempool_1gac78e7cbbf707f8e5399843aae28b2d9d"></span><em class="property">typedef </em>os_error_t <code class="descname">os_mempool_put_fn</code><span class="sig-paren">(</span>struct os_mempool_ext<em>&nbsp;*ome</em>, void<em>&nbsp;*data</em>, void<em>&nbsp;*arg</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_mempool_put_fn" title="Permalink to this definition">?</a></dt>
+<dd><p>Block put callback function. </p>
+<p>If configured, this callback gets executed whenever a block is freed to the corresponding extended mempool. Note: The <a class="reference internal" href="#group___o_s_mempool_1gaf6178bdc593729880d9d2bb7e23e11b0"><span class="std std-ref">os_memblock_put()</span></a> function calls this callback instead of freeing the block itself. Therefore, it is the callback?s responsibility to free the block via a call to <a class="reference internal" href="#group___o_s_mempool_1gacbcaf7e356d49c4f84612e5a0d882596"><span class="std std-ref">os_memblock_put_from_cb()</span></a>.</p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>Indicates whether the block was successfully freed. A non-zero value should only be returned if the block was not successfully released back to its pool. </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">ome</span></code>: The extended mempool that a block is being freed back to. </li>
+<li><code class="docutils literal notranslate"><span class="pre">data</span></code>: The block being freed. </li>
+<li><code class="docutils literal notranslate"><span class="pre">arg</span></code>: Optional argument configured along with the callback.</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="typedef">
+<dt id="c.os_membuf_t">
+<span class="target" id="group___o_s_mempool_1ga0615acb24ae94e5a5a337b424c70fd6a"></span><em class="property">typedef </em>uint32_t <code class="descname">os_membuf_t</code><a class="headerlink" href="#c.os_membuf_t" title="Permalink to this definition">?</a></dt>
+<dd></dd></dl>
+
+<dl class="function">
+<dt id="c.os_mempool_info_get_next">
+<span class="target" id="group___o_s_mempool_1gae80195d443ae18bf7298eabcfe550b22"></span>struct os_mempool* <code class="descname">os_mempool_info_get_next</code><span class="sig-paren">(</span>struct  os_mempool <em>&nbsp;*</em>, struct  os_mempool_info <em>&nbsp;*</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_mempool_info_get_next" title="Permalink to this definition">?</a></dt>
+<dd><p>Get information about the next system memory pool. </p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>The next memory pool in the list to get information about, or NULL when at the last memory pool. </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">mempool</span></code>: The current memory pool, or NULL if starting iteration. </li>
+<li><code class="docutils literal notranslate"><span class="pre">info</span></code>: A pointer to the structure to return memory pool information into.</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_mempool_init">
+<span class="target" id="group___o_s_mempool_1gadcf2c1941c73b2ad97e05a1d36e8234d"></span>os_error_t <code class="descname">os_mempool_init</code><span class="sig-paren">(</span>struct  os_mempool  *<em>&nbsp;mp</em>, uint16_t<em>&nbsp;blocks</em>, uint32_t<em>&nbsp;block_size</em>, void *<em>&nbsp;membuf</em>, char *<em>&nbsp;name</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_mempool_init" title="Permalink to this definition">?</a></dt>
+<dd><p>Initialize a memory pool. </p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>os_error_t </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">mp</span></code>: Pointer to a pointer to a mempool </li>
+<li><code class="docutils literal notranslate"><span class="pre">blocks</span></code>: The number of blocks in the pool </li>
+<li><code class="docutils literal notranslate"><span class="pre">blocks_size</span></code>: The size of the block, in bytes. </li>
+<li><code class="docutils literal notranslate"><span class="pre">membuf</span></code>: Pointer to memory to contain blocks. </li>
+<li><code class="docutils literal notranslate"><span class="pre">name</span></code>: Name of the pool.</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_mempool_ext_init">
+<span class="target" id="group___o_s_mempool_1gacb506516fd3695bf9649aef5ac384d53"></span>os_error_t <code class="descname">os_mempool_ext_init</code><span class="sig-paren">(</span>struct  os_mempool_ext  *<em>&nbsp;mpe</em>, uint16_t<em>&nbsp;blocks</em>, uint32_t<em>&nbsp;block_size</em>, void *<em>&nbsp;membuf</em>, char *<em>&nbsp;name</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_mempool_ext_init" title="Permalink to this definition">?</a></dt>
+<dd><p>Initializes an extended memory pool. </p>
+<p>Extended attributes (e.g., callbacks) are not specified when this function is called; they are assigned manually after initialization.</p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>os_error_t </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">mpe</span></code>: The extended memory pool to initialize. </li>
+<li><code class="docutils literal notranslate"><span class="pre">blocks</span></code>: The number of blocks in the pool. </li>
+<li><code class="docutils literal notranslate"><span class="pre">block_size</span></code>: The size of each block, in bytes. </li>
+<li><code class="docutils literal notranslate"><span class="pre">membuf</span></code>: Pointer to memory to contain blocks. </li>
+<li><code class="docutils literal notranslate"><span class="pre">name</span></code>: Name of the pool.</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_mempool_is_sane">
+<span class="target" id="group___o_s_mempool_1ga94f119d4163b6ad4b5c41f11c0628e5d"></span>bool <code class="descname">os_mempool_is_sane</code><span class="sig-paren">(</span>const struct  os_mempool  *<em>&nbsp;mp</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_mempool_is_sane" title="Permalink to this definition">?</a></dt>
+<dd><p>Performs an integrity check of the specified mempool. </p>
+<p>This function attempts to detect memory corruption in the specified memory pool.</p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>true if the memory pool passes the integrity check; false if the memory pool is corrupt. </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">mp</span></code>: The mempool to check.</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_memblock_from">
+<span class="target" id="group___o_s_mempool_1gaeda86bc0aa05a01cffe5934bede45041"></span>int <code class="descname">os_memblock_from</code><span class="sig-paren">(</span>const struct  os_mempool  *<em>&nbsp;mp</em>, const void *<em>&nbsp;block_addr</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_memblock_from" title="Permalink to this definition">?</a></dt>
+<dd><p>Checks if a memory block was allocated from the specified mempool. </p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>0 if the block does not belong to the mempool; 1 if the block does belong to the mempool. </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">mp</span></code>: The mempool to check as parent. </li>
+<li><code class="docutils literal notranslate"><span class="pre">block_addr</span></code>: The memory block to check as child.</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_memblock_get">
+<span class="target" id="group___o_s_mempool_1ga5b08e22ecfe88e4563c9577354410676"></span>void* <code class="descname">os_memblock_get</code><span class="sig-paren">(</span>struct  os_mempool  *<em>&nbsp;mp</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_memblock_get" title="Permalink to this definition">?</a></dt>
+<dd><p>Get a memory block from a memory pool. </p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>void* Pointer to block if available; NULL otherwise </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">mp</span></code>: Pointer to the memory pool</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_memblock_put_from_cb">
+<span class="target" id="group___o_s_mempool_1gacbcaf7e356d49c4f84612e5a0d882596"></span>os_error_t <code class="descname">os_memblock_put_from_cb</code><span class="sig-paren">(</span>struct  os_mempool  *<em>&nbsp;mp</em>, void *<em>&nbsp;block_addr</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_memblock_put_from_cb" title="Permalink to this definition">?</a></dt>
+<dd><p>Puts the memory block back into the pool, ignoring the put callback, if any. </p>
+<p>This function should only be called from a put callback to free a block without causing infinite recursion.</p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>os_error_t </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">mp</span></code>: Pointer to memory pool </li>
+<li><code class="docutils literal notranslate"><span class="pre">block_addr</span></code>: Pointer to memory block</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_memblock_put">
+<span class="target" id="group___o_s_mempool_1gaf6178bdc593729880d9d2bb7e23e11b0"></span>os_error_t <code class="descname">os_memblock_put</code><span class="sig-paren">(</span>struct  os_mempool  *<em>&nbsp;mp</em>, void *<em>&nbsp;block_addr</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_memblock_put" title="Permalink to this definition">?</a></dt>
+<dd><p>Puts the memory block back into the pool. </p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>os_error_t </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">mp</span></code>: Pointer to memory pool </li>
+<li><code class="docutils literal notranslate"><span class="pre">block_addr</span></code>: Pointer to memory block</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="define">
+<dt id="c.OS_MEMPOOL_F_EXT">
+<span class="target" id="group___o_s_mempool_1gabc6a0dba610f01a2fcbedb9902f98260"></span><code class="descname">OS_MEMPOOL_F_EXT</code><a class="headerlink" href="#c.OS_MEMPOOL_F_EXT" title="Permalink to this definition">?</a></dt>
+<dd><p>Indicates an extended mempool. </p>
+<p>Address can be safely cast to (struct os_mempool_ext *). </p>
+</dd></dl>
+
+<dl class="define">
+<dt id="c.OS_MEMPOOL_INFO_NAME_LEN">
+<span class="target" id="group___o_s_mempool_1gae23cbfc2e7590d009c651bce00a58d95"></span><code class="descname">OS_MEMPOOL_INFO_NAME_LEN</code><a class="headerlink" href="#c.OS_MEMPOOL_INFO_NAME_LEN" title="Permalink to this definition">?</a></dt>
+<dd></dd></dl>
+
+<dl class="define">
+<dt id="c.OS_MEMPOOL_SIZE">
+<span class="target" id="group___o_s_mempool_1gac5014e0e9c9e52c42d228158e5fc92c6"></span><code class="descname">OS_MEMPOOL_SIZE</code><span class="sig-paren">(</span>n, blksize<span class="sig-paren">)</span><a class="headerlink" href="#c.OS_MEMPOOL_SIZE" title="Permalink to this definition">?</a></dt>
+<dd></dd></dl>
+
+<dl class="define">
+<dt id="c.OS_MEMPOOL_BYTES">
+<span class="target" id="group___o_s_mempool_1ga7fa594c641e3c1143fc641e80c6029ee"></span><code class="descname">OS_MEMPOOL_BYTES</code><span class="sig-paren">(</span>n, blksize<span class="sig-paren">)</span><a class="headerlink" href="#c.OS_MEMPOOL_BYTES" title="Permalink to this definition">?</a></dt>
+<dd><p>Calculates the number of bytes required to initialize a memory pool. </p>
+</dd></dl>
+
+<dl class="class">
+<dt id="_CPPv311os_memblock">
+<span id="_CPPv211os_memblock"></span><span id="os_memblock"></span><span class="target" id="structos__memblock"></span><em class="property">struct </em><code class="descname">os_memblock</code><a class="headerlink" href="#_CPPv311os_memblock" title="Permalink to this definition">?</a><br /></dt>
+<dd><em>#include &lt;os_mempool.h&gt;</em><p>A memory block structure. </p>
+<p>This simply contains a pointer to the free list chain and is only used when the block is on the free list. When the block has been removed from the free list the entire memory block is usable by the caller. </p>
+</dd></dl>
+
+<dl class="class">
+<dt id="_CPPv310os_mempool">
+<span id="_CPPv210os_mempool"></span><span id="os_mempool"></span><span class="target" id="structos__mempool"></span><em class="property">struct </em><code class="descname">os_mempool</code><a class="headerlink" href="#_CPPv310os_mempool" title="Permalink to this definition">?</a><br /></dt>
+<dd><em>#include &lt;os_mempool.h&gt;</em><p>Memory pool. </p>
+<div class="breathe-sectiondef docutils container">
+<p class="breathe-sectiondef-title rubric">Public Members</p>
+<dl class="variable">
+<dt id="c.os_mempool::mp_block_size">
+<span class="target" id="structos__mempool_1aa8b69c7241eef307bfdab6558f7a76fc"></span>uint32_t <code class="descname">mp_block_size</code><a class="headerlink" href="#c.os_mempool::mp_block_size" title="Permalink to this definition">?</a></dt>
+<dd><p>Size of the memory blocks, in bytes. </p>
+</dd></dl>
+
+<dl class="variable">
+<dt id="c.os_mempool::mp_num_blocks">
+<span class="target" id="structos__mempool_1a1070d64ec9462682b859afa551dc4f7d"></span>uint16_t <code class="descname">mp_num_blocks</code><a class="headerlink" href="#c.os_mempool::mp_num_blocks" title="Permalink to this definition">?</a></dt>
+<dd><p>The number of memory blocks. </p>
+</dd></dl>
+
+<dl class="variable">
+<dt id="c.os_mempool::mp_num_free">
+<span class="target" id="structos__mempool_1a330c95fc173c50c2c724d044e3260eaa"></span>uint16_t <code class="descname">mp_num_free</code><a class="headerlink" href="#c.os_mempool::mp_num_free" title="Permalink to this definition">?</a></dt>
+<dd><p>The number of free blocks left. </p>
+</dd></dl>
+
+<dl class="variable">
+<dt id="c.os_mempool::mp_min_free">
+<span class="target" id="structos__mempool_1adcae8c4d47359ce32b49e112f925a53f"></span>uint16_t <code class="descname">mp_min_free</code><a class="headerlink" href="#c.os_mempool::mp_min_free" title="Permalink to this definition">?</a></dt>
+<dd><p>The lowest number of free blocks seen. </p>
+</dd></dl>
+
+<dl class="variable">
+<dt id="c.os_mempool::mp_flags">
+<span class="target" id="structos__mempool_1a08fe88157701d4a1ec6162a8292e1b50"></span>uint8_t <code class="descname">mp_flags</code><a class="headerlink" href="#c.os_mempool::mp_flags" title="Permalink to this definition">?</a></dt>
+<dd><p>Bitmap of OS_MEMPOOL_F_[?] values. </p>
+</dd></dl>
+
+<dl class="variable">
+<dt id="c.os_mempool::mp_membuf_addr">
+<span class="target" id="structos__mempool_1ac61a68914819ed8a178fbc9dda26b8d0"></span>uint32_t <code class="descname">mp_membuf_addr</code><a class="headerlink" href="#c.os_mempool::mp_membuf_addr" title="Permalink to this definition">?</a></dt>
+<dd><p>Address of memory buffer used by pool. </p>
+</dd></dl>
+
+<dl class="variable">
+<dt id="c.os_mempool::name">
+<span class="target" id="structos__mempool_1ac10eae51516dfaa843213b7c154cb92d"></span>char* <code class="descname">name</code><a class="headerlink" href="#c.os_mempool::name" title="Permalink to this definition">?</a></dt>
+<dd><p>Name for memory block. </p>
+</dd></dl>
+
 </div>
+</dd></dl>
+
+<dl class="class">
+<dt id="_CPPv315os_mempool_info">
+<span id="_CPPv215os_mempool_info"></span><span id="os_mempool_info"></span><span class="target" id="structos__mempool__info"></span><em class="property">struct </em><code class="descname">os_mempool_info</code><a class="headerlink" href="#_CPPv315os_mempool_info" title="Permalink to this definition">?</a><br /></dt>
+<dd><em>#include &lt;os_mempool.h&gt;</em><p>Information describing a memory pool, used to return OS information to the management layer. </p>
+<div class="breathe-sectiondef docutils container">
+<p class="breathe-sectiondef-title rubric">Public Members</p>
+<dl class="variable">
+<dt id="c.os_mempool_info::omi_block_size">
+<span class="target" id="structos__mempool__info_1afe44d778f68b1ac45af5bfa4a21e7a03"></span>int <code class="descname">omi_block_size</code><a class="headerlink" href="#c.os_mempool_info::omi_block_size" title="Permalink to this definition">?</a></dt>
+<dd><p>Size of the memory blocks in the pool. </p>
+</dd></dl>
+
+<dl class="variable">
+<dt id="c.os_mempool_info::omi_num_blocks">
+<span class="target" id="structos__mempool__info_1a396fcdd3a698a8df11dc848a3ea44006"></span>int <code class="descname">omi_num_blocks</code><a class="headerlink" href="#c.os_mempool_info::omi_num_blocks" title="Permalink to this definition">?</a></dt>
+<dd><p>Number of memory blocks in the pool. </p>
+</dd></dl>
+
+<dl class="variable">
+<dt id="c.os_mempool_info::omi_num_free">
+<span class="target" id="structos__mempool__info_1adeec12d679ad4825c39aa615aecdf2b7"></span>int <code class="descname">omi_num_free</code><a class="headerlink" href="#c.os_mempool_info::omi_num_free" title="Permalink to this definition">?</a></dt>
+<dd><p>Number of free memory blocks. </p>
+</dd></dl>
+
+<dl class="variable">
+<dt id="c.os_mempool_info::omi_min_free">
+<span class="target" id="structos__mempool__info_1a2dea3179c694145c6d7d478529968548"></span>int <code class="descname">omi_min_free</code><a class="headerlink" href="#c.os_mempool_info::omi_min_free" title="Permalink to this definition">?</a></dt>
+<dd><p>Minimum number of free memory blocks ever. </p>
+</dd></dl>
+
+<dl class="variable">
+<dt>
+<span class="target" id="structos__mempool__info_1a616071f643a7cc73b1564cf7b76fc052"></span><code class="descname">char os_mempool_info::omi_name[OS_MEMPOOL_INFO_NAME_LEN]</code></dt>
+<dd><p>Name of the memory pool. </p>
+</dd></dl>
+
+</div>
+</dd></dl>
+
 </div>
 </div>
 
@@ -454,10 +632,10 @@ <h2>API<a class="headerlink" href="#api" title="Permalink to this headline">?</
                   
     <div class="rst-footer-buttons row" role="navigation" aria-label="footer navigation">
       
-        <a href="../heap/heap.html" class="btn btn-neutral float-right" title="Heap" accesskey="n">Next: Heap <span class="fa fa-arrow-circle-right"></span></a>
+        <a href="../mbuf/mbuf.html" class="btn btn-neutral float-right" title="Mbufs" accesskey="n">Next: Mbufs <span class="fa fa-arrow-circle-right"></span></a>
       
       
-        <a href="../mutex/mutex.html" class="btn btn-neutral" title="Mutex" accesskey="p"><span class="fa fa-arrow-circle-left"></span> Previous: Mutex</a>
+        <a href="../heap/heap.html" class="btn btn-neutral" title="Heap" accesskey="p"><span class="fa fa-arrow-circle-left"></span> Previous: Heap</a>
       
     </div>
 
diff --git a/develop/os/core_os/mqueue/mqueue.html b/develop/os/core_os/mqueue/mqueue.html
deleted file mode 100644
index 10c411a97..000000000
--- a/develop/os/core_os/mqueue/mqueue.html
+++ /dev/null
@@ -1,444 +0,0 @@
-
-
-<!DOCTYPE html>
-<html lang="en">
-  <head>
-    <meta charset="utf-8">
-    <meta http-equiv="X-UA-Compatible" content="IE=edge">
-    <meta name="viewport" content="width=device-width, initial-scale=1.0">
-
-    
-
-    
-    <title>Mqueue &mdash; Apache Mynewt 1.3.0 documentation</title>
-    
-
-    
-    
-      <link rel="shortcut icon" href="../../../_static/mynewt-logo-only-newt32x32.png"/>
-    
-
-    
-
-    <link rel="stylesheet" href="../../../_static/css/theme.css" type="text/css" />
-
-    
-      <link rel="stylesheet" href="../../../_static/css/sphinx_theme.css" type="text/css" />
-    
-      <link rel="stylesheet" href="../../../_static/css/bootstrap-3.0.3.min.css" type="text/css" />
-    
-      <link rel="stylesheet" href="../../../_static/css/v2.css" type="text/css" />
-    
-      <link rel="stylesheet" href="../../../_static/css/custom.css" type="text/css" />
-    
-      <link rel="stylesheet" href="../../../_static/css/restructuredtext.css" type="text/css" />
-    
-
-    
-
-    <link rel="stylesheet" href="../../../_static/css/overrides.css" type="text/css" />
-          <link rel="index" title="Index"
-                href="../../../genindex.html"/>
-          <link rel="search" title="Search" href="../../../search.html"/>
-      <link rel="top" title="Apache Mynewt 1.3.0 documentation" href="../../../index.html"/>
-          <link rel="up" title="Mynewt Core OS" href="../mynewt_os.html"/>
-          <link rel="next" title="Sanity" href="../sanity/sanity.html"/>
-          <link rel="prev" title="Msys" href="../msys/msys.html"/> 
-
-    
-    <script src="../../../_static/js/modernizr.min.js"></script>
-
-    
-    <script>
-    (function(i, s, o, g, r, a, m) {
-	i["GoogleAnalyticsObject"] = r;
-	(i[r] =
-		i[r] ||
-		function() {
-			(i[r].q = i[r].q || []).push(arguments);
-		}),
-		(i[r].l = 1 * new Date());
-	(a = s.createElement(o)), (m = s.getElementsByTagName(o)[0]);
-	a.async = 1;
-	a.src = g;
-	m.parentNode.insertBefore(a, m);
-})(window, document, "script", "//www.google-analytics.com/analytics.js", "ga");
-
-ga("create", "UA-72162311-1", "auto");
-ga("send", "pageview");
-</script>
-    
-
-  </head>
-
-  <body class="not-front page-documentation" role="document" >
-    <div id="wrapper">
-      <div class="container">
-    <div id="banner" class="row v2-main-banner">
-        <a class="logo-cell" href="/">
-            <img class="logo" src="../../../_static/img/logo.png">
-        </a>
-        <div class="tagline-cell">
-            <h4 class="tagline">An OS to build, deploy and securely manage billions of devices</h4>
-        </div>
-        <div class="news-cell">
-            <div class="well">
-              <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (December 13, 2017)
-            </div>
-        </div>
-    </div>
-</div>
-      
-<header>
-    <nav id="navbar" class="navbar navbar-inverse" role="navigation">
-        <div class="container">
-            <!-- Collapsed navigation -->
-            <div class="navbar-header">
-                <!-- Expander button -->
-                <button type="button" class="navbar-toggle" data-toggle="collapse" data-target=".navbar-collapse">
-                    <span class="sr-only">Toggle navigation</span>
-                    <span class="icon-bar"></span>
-                    <span class="icon-bar"></span>
-                    <span class="icon-bar"></span>
-                </button>
-
-            </div>
-
-            <!-- Expanded navigation -->
-            <div class="navbar-collapse collapse">
-                <!-- Main navigation -->
-                <ul class="nav navbar-nav navbar-right">
-                    <li>
-                        <a href="/"><i class="fa fa-home" style="font-size: larger;"></i></a>
-                    </li>
-                    <li class="important">
-                        <a href="/get_started/quick_start.html">Quick Start</a>
-                    </li>
-                    <li>
-                        <a href="/about/">About</a>
-                    </li>
-                    <li>
-                        <a href="/talks/">Talks</a>
-                    </li>
-                    <li class="active">
-                        <a href="/documentation/">Documentation</a>
-                    </li>
-                    <li>
-                        <a href="/download/">Download</a>
-                    </li>
-                    <li>
-                        <a href="/community/">Community</a>
-                    </li>
-                    <li>
-                        <a href="/events/">Events</a>
-                    </li>
-                </ul>
-
-                <!-- Search, Navigation and Repo links -->
-                <ul class="nav navbar-nav navbar-right">
-                    
-                </ul>
-            </div>
-        </div>
-    </nav>
-</header>
-      <!-- STARTS MAIN CONTENT -->
-      <div id="main-content">
-        
-
-
-
-
-
-<div id="breadcrumb">
-  <div class="container">
-    <a href="/documentation/">Docs</a> /
-    
-      <a href="../../os_user_guide.html">OS User Guide</a> /
-    
-      <a href="../mynewt_os.html">Mynewt Core OS</a> /
-    
-    Mqueue
-    
-  <div class="sourcelink">
-    <a href="https://github.com/apache/mynewt-core/edit/master/docs/os/core_os/mqueue/mqueue.rst" class="icon icon-github"
-           rel="nofollow"> Edit on GitHub</a>
-</div>
-  </div>
-</div>
-        <!-- STARTS CONTAINER -->
-        <div class="container">
-          <!-- STARTS .content -->
-          <div id="content" class="row">
-            
-            <!-- STARTS .container-sidebar -->
-<div class="container-sidebar col-xs-12 col-sm-3">
-  <div id="docSidebar" class="sticky-container">
-    <div role="search" class="sphinx-search">
-  <form id="rtd-search-form" class="wy-form" action="../../../search.html" method="get">
-    <input type="text" name="q" placeholder="Search documentation" class="search-documentation" />
-    <input type="hidden" name="check_keywords" value="yes" />
-    <input type="hidden" name="area" value="default" />
-  </form>
-</div>
-    
-<!-- Note: only works when deployed -->
-<select class="form-control" onchange="if (this.value) window.location.href=this.value">
-    <option
-      value="/develop"
-      selected
-      >
-      Version: develop (latest - mynewt-documentation)
-    </option>
-    <option
-      value="/latest/os/introduction"
-      >
-      Version: master (latest - mynewt-site)
-    </option>
-    <option
-      value="/v1_2_0/os/introduction"
-      >
-      Version: 1.2.0
-    </option>
-    <option
-      value="/v1_1_0/os/introduction">
-      Version: 1.1.0
-    </option>
-    <option
-      value="/v1_0_0/os/introduction">
-      Version: 1.0.0
-    </option>
-    <option
-      value="/v0_9_0/os/introduction">
-      Version: 0_9_0
-    </option>
-</select>
-    <div class="region region-sidebar">
-      <div class="docs-menu">
-      
-        
-        
-            <ul class="current">
-<li class="toctree-l1"><a class="reference internal" href="../../../index.html">Introduction</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../../get_started/index.html">Setup &amp; Get Started</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../../concepts.html">Concepts</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../../tutorials/tutorials.html">Tutorials</a></li>
-<li class="toctree-l1 current"><a class="reference internal" href="../../os_user_guide.html">OS User Guide</a><ul class="current">
-<li class="toctree-l2 current"><a class="reference internal" href="../mynewt_os.html">OS Core</a><ul class="current">
-<li class="toctree-l3"><a class="reference internal" href="../context_switch/context_switch.html">Scheduler</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../cputime/os_cputime.html">CPU Time</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../time/os_time.html">OS Time</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../task/task.html">Task</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../event_queue/event_queue.html">Event Queues</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../semaphore/semaphore.html">Semaphore</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../mutex/mutex.html">Mutex</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../memory_pool/memory_pool.html">Memory Pools</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../heap/heap.html">Heap</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../mbuf/mbuf.html">Mbufs</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../msys/msys.html">Msys</a></li>
-<li class="toctree-l3 current"><a class="current reference internal" href="#">Mqueue</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../sanity/sanity.html">Sanity</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../callout/callout.html">Callout</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../API.html">API</a></li>
-</ul>
-</li>
-<li class="toctree-l2"><a class="reference internal" href="../porting/port_os.html">Porting Mynewt OS</a></li>
-<li class="toctree-l2"><a class="reference internal" href="../../modules/console/console.html">Console</a></li>
-<li class="toctree-l2"><a class="reference internal" href="../../modules/sysinitconfig/sysinitconfig.html">System Configuration and Initialization</a></li>
-</ul>
-</li>
-<li class="toctree-l1"><a class="reference internal" href="../../../network/ble/ble_intro.html">BLE User Guide</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../../newt/index.html">Newt Tool Guide</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../../newtmgr/index.html">Newt Manager Guide</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../../misc/index.html">Appendix</a></li>
-</ul>
-
-        
-      
-      </div>
-    </div>
-  </div>
-  <!-- ENDS STICKY CONTAINER -->
-</div>
-<!-- ENDS .container-sidebar -->
-
-            <div class="col-xs-12 col-sm-9">
-              <div class="alert alert-info" role="alert">
-  <p>
-    This is the development version of Apache Mynewt documentation. As such it may not be as complete as the latest
-    stable version of the documentation found <a href="/latest/os/introduction/">here</a>.
-  </p>
-  <p>
-    To improve this documentation please visit <a href="https://github.com/apache/mynewt-documentation">https://github.com/apache/mynewt-documentation</a>.
-  </p>
-</div>
-              
-              <div class="">
-                <div class="rst-content">
-                  <div role="main" class="document" itemscope="itemscope" itemtype="http://schema.org/Article">
-                   <div itemprop="articleBody">
-                    
-  <div class="section" id="mqueue">
-<h1>Mqueue<a class="headerlink" href="#mqueue" title="Permalink to this headline">?</a></h1>
-<p>The mqueue construct allows a task to wake up when it receives data.
-Typically, this data is in the form of packets received over a network.
-A common networking stack operation is to put a packet on a queue and
-post an event to the task monitoring that queue. When the task handles
-the event, it processes each packet on the packet queue.</p>
-<div class="section" id="using-mqueue">
-<h2>Using Mqueue<a class="headerlink" href="#using-mqueue" title="Permalink to this headline">?</a></h2>
-<p>The following code sample demonstrates how to use an mqueue. In this
-example:</p>
-<ul class="simple">
-<li>packets are put on a receive queue</li>
-<li>a task processes each packet on the queue (increments a receive
-counter)</li>
-</ul>
-<p>Not shown in the code example is a call <code class="docutils literal notranslate"><span class="pre">my_task_rx_data_func</span></code>.
-Presumably, some other code will call this API.</p>
-<div class="code c highlight-none notranslate"><div class="highlight"><pre><span></span>uint32_t pkts_rxd;
-struct os_mqueue rxpkt_q;
-struct os_eventq my_task_evq;
-
-/**
- * Removes each packet from the receive queue and processes it.
- */
-void
-process_rx_data_queue(void)
-{
-    struct os_mbuf *om;
-
-    while ((om = os_mqueue_get(&amp;rxpkt_q)) != NULL) {
-        ++pkts_rxd;
-        os_mbuf_free_chain(om);
-    }
-}
-
-/**
- * Called when a packet is received.
- */
-int
-my_task_rx_data_func(struct os_mbuf *om)
-{
-    int rc;
-
-    /* Enqueue the received packet and wake up the listening task. */
-    rc = os_mqueue_put(&amp;rxpkt_q, &amp;my_task_evq, om);
-    if (rc != 0) {
-        return -1;
-    }
-
-    return 0;
-}
-
-void
-my_task_handler(void *arg)
-{
-    struct os_event *ev;
-    struct os_callout_func *cf;
-    int rc;
-
-    /* Initialize eventq */
-    os_eventq_init(&amp;my_task_evq);
-
-    /* Initialize mqueue */
-    os_mqueue_init(&amp;rxpkt_q, NULL);
-
-    /* Process each event posted to our eventq.  When there are no events to
-     * process, sleep until one arrives.
-     */
-    while (1) {
-        os_eventq_run(&amp;my_task_evq);
-    }
-}
-</pre></div>
-</div>
-</div>
-<div class="section" id="data-structures">
-<h2>Data Structures<a class="headerlink" href="#data-structures" title="Permalink to this headline">?</a></h2>
-<div class="code c highlight-none notranslate"><div class="highlight"><pre><span></span>struct os_mqueue {
-    STAILQ_HEAD(, os_mbuf_pkthdr) mq_head;
-    struct os_event mq_ev;
-};
-</pre></div>
-</div>
-</div>
-<div class="section" id="api">
-<h2>API<a class="headerlink" href="#api" title="Permalink to this headline">?</a></h2>
-<div class="admonition warning">
-<p class="first admonition-title">Warning</p>
-<p class="last">doxygengroup: Cannot find namespace ?OSMqueue? in doxygen xml output for project ?mynewt-core? from directory: mynewt-core-xml</p>
-</div>
-</div>
-</div>
-
-
-                   </div>
-                  </div>
-                  
-    <div class="rst-footer-buttons row" role="navigation" aria-label="footer navigation">
-      
-        <a href="../sanity/sanity.html" class="btn btn-neutral float-right" title="Sanity" accesskey="n">Next: Sanity <span class="fa fa-arrow-circle-right"></span></a>
-      
-      
-        <a href="../msys/msys.html" class="btn btn-neutral" title="Msys" accesskey="p"><span class="fa fa-arrow-circle-left"></span> Previous: Msys</a>
-      
-    </div>
-
-                </div>
-              </div>
-            </div>
-            <!-- ENDS CONTENT SECTION -->
-          </div>
-          <!-- ENDS .content -->
-        </div>
-      </div>
-      <footer>
-  <div class="container">
-    <div class="row">
-      <div class="col-xs-12">
-          
-              <p class="copyright">Apache Mynewt is available under Apache License, version 2.0.</p>
-          
-      </div>
-      <div class="col-xs-12">
-          <div class="logos">
-              <img src="../../../_static/img/asf_logo_wide_small.png" alt="Apache" title="Apache">
-              <small class="footnote">
-                Apache Mynewt, Mynewt, Apache, the Apache feather logo, and the Apache Mynewt project logo are either
-                registered trademarks or trademarks of the Apache Software Foundation in the United States and other countries.
-              </small>
-              <a href="https://join.slack.com/mynewt/shared_invite/MTkwMTg1ODM1NTg5LTE0OTYxNzQ4NzQtZTU1YmNhYjhkMg">
-                <img src="../../../_static/img/add_to_slack.png" alt="Slack Icon" title="Join our Slack Community" />
-              </a>
-          </div>
-      </div>
-    </div>
-  </div>
-</footer>
-    </div>
-    <!-- ENDS #wrapper -->
-
-  
-
-    <script type="text/javascript">
-        var DOCUMENTATION_OPTIONS = {
-            URL_ROOT:'../../../',
-            VERSION:'1.3.0',
-            COLLAPSE_INDEX:false,
-            FILE_SUFFIX:'.html',
-            HAS_SOURCE:  true,
-            SOURCELINK_SUFFIX: '.txt'
-        };
-    </script>
-      <script type="text/javascript" src="../../../_static/jquery.js"></script>
-      <script type="text/javascript" src="../../../_static/underscore.js"></script>
-      <script type="text/javascript" src="../../../_static/doctools.js"></script>
-      <script type="text/javascript" src="../../../_static/js/bootstrap-3.0.3.min.js"></script>
-      <script type="text/javascript" src="../../../_static/js/affix.js"></script>
-      <script type="text/javascript" src="../../../_static/js/main.js"></script>
-
-   
-
-  </body>
-</html>
\ No newline at end of file
diff --git a/develop/os/core_os/msys/msys.html b/develop/os/core_os/msys/msys.html
deleted file mode 100644
index 79bbbb5f8..000000000
--- a/develop/os/core_os/msys/msys.html
+++ /dev/null
@@ -1,389 +0,0 @@
-
-
-<!DOCTYPE html>
-<html lang="en">
-  <head>
-    <meta charset="utf-8">
-    <meta http-equiv="X-UA-Compatible" content="IE=edge">
-    <meta name="viewport" content="width=device-width, initial-scale=1.0">
-
-    
-
-    
-    <title>Msys &mdash; Apache Mynewt 1.3.0 documentation</title>
-    
-
-    
-    
-      <link rel="shortcut icon" href="../../../_static/mynewt-logo-only-newt32x32.png"/>
-    
-
-    
-
-    <link rel="stylesheet" href="../../../_static/css/theme.css" type="text/css" />
-
-    
-      <link rel="stylesheet" href="../../../_static/css/sphinx_theme.css" type="text/css" />
-    
-      <link rel="stylesheet" href="../../../_static/css/bootstrap-3.0.3.min.css" type="text/css" />
-    
-      <link rel="stylesheet" href="../../../_static/css/v2.css" type="text/css" />
-    
-      <link rel="stylesheet" href="../../../_static/css/custom.css" type="text/css" />
-    
-      <link rel="stylesheet" href="../../../_static/css/restructuredtext.css" type="text/css" />
-    
-
-    
-
-    <link rel="stylesheet" href="../../../_static/css/overrides.css" type="text/css" />
-          <link rel="index" title="Index"
-                href="../../../genindex.html"/>
-          <link rel="search" title="Search" href="../../../search.html"/>
-      <link rel="top" title="Apache Mynewt 1.3.0 documentation" href="../../../index.html"/>
-          <link rel="up" title="Mynewt Core OS" href="../mynewt_os.html"/>
-          <link rel="next" title="Mqueue" href="../mqueue/mqueue.html"/>
-          <link rel="prev" title="Mbufs" href="../mbuf/mbuf.html"/> 
-
-    
-    <script src="../../../_static/js/modernizr.min.js"></script>
-
-    
-    <script>
-    (function(i, s, o, g, r, a, m) {
-	i["GoogleAnalyticsObject"] = r;
-	(i[r] =
-		i[r] ||
-		function() {
-			(i[r].q = i[r].q || []).push(arguments);
-		}),
-		(i[r].l = 1 * new Date());
-	(a = s.createElement(o)), (m = s.getElementsByTagName(o)[0]);
-	a.async = 1;
-	a.src = g;
-	m.parentNode.insertBefore(a, m);
-})(window, document, "script", "//www.google-analytics.com/analytics.js", "ga");
-
-ga("create", "UA-72162311-1", "auto");
-ga("send", "pageview");
-</script>
-    
-
-  </head>
-
-  <body class="not-front page-documentation" role="document" >
-    <div id="wrapper">
-      <div class="container">
-    <div id="banner" class="row v2-main-banner">
-        <a class="logo-cell" href="/">
-            <img class="logo" src="../../../_static/img/logo.png">
-        </a>
-        <div class="tagline-cell">
-            <h4 class="tagline">An OS to build, deploy and securely manage billions of devices</h4>
-        </div>
-        <div class="news-cell">
-            <div class="well">
-              <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (December 13, 2017)
-            </div>
-        </div>
-    </div>
-</div>
-      
-<header>
-    <nav id="navbar" class="navbar navbar-inverse" role="navigation">
-        <div class="container">
-            <!-- Collapsed navigation -->
-            <div class="navbar-header">
-                <!-- Expander button -->
-                <button type="button" class="navbar-toggle" data-toggle="collapse" data-target=".navbar-collapse">
-                    <span class="sr-only">Toggle navigation</span>
-                    <span class="icon-bar"></span>
-                    <span class="icon-bar"></span>
-                    <span class="icon-bar"></span>
-                </button>
-
-            </div>
-
-            <!-- Expanded navigation -->
-            <div class="navbar-collapse collapse">
-                <!-- Main navigation -->
-                <ul class="nav navbar-nav navbar-right">
-                    <li>
-                        <a href="/"><i class="fa fa-home" style="font-size: larger;"></i></a>
-                    </li>
-                    <li class="important">
-                        <a href="/get_started/quick_start.html">Quick Start</a>
-                    </li>
-                    <li>
-                        <a href="/about/">About</a>
-                    </li>
-                    <li>
-                        <a href="/talks/">Talks</a>
-                    </li>
-                    <li class="active">
-                        <a href="/documentation/">Documentation</a>
-                    </li>
-                    <li>
-                        <a href="/download/">Download</a>
-                    </li>
-                    <li>
-                        <a href="/community/">Community</a>
-                    </li>
-                    <li>
-                        <a href="/events/">Events</a>
-                    </li>
-                </ul>
-
-                <!-- Search, Navigation and Repo links -->
-                <ul class="nav navbar-nav navbar-right">
-                    
-                </ul>
-            </div>
-        </div>
-    </nav>
-</header>
-      <!-- STARTS MAIN CONTENT -->
-      <div id="main-content">
-        
-
-
-
-
-
-<div id="breadcrumb">
-  <div class="container">
-    <a href="/documentation/">Docs</a> /
-    
-      <a href="../../os_user_guide.html">OS User Guide</a> /
-    
-      <a href="../mynewt_os.html">Mynewt Core OS</a> /
-    
-    Msys
-    
-  <div class="sourcelink">
-    <a href="https://github.com/apache/mynewt-core/edit/master/docs/os/core_os/msys/msys.rst" class="icon icon-github"
-           rel="nofollow"> Edit on GitHub</a>
-</div>
-  </div>
-</div>
-        <!-- STARTS CONTAINER -->
-        <div class="container">
-          <!-- STARTS .content -->
-          <div id="content" class="row">
-            
-            <!-- STARTS .container-sidebar -->
-<div class="container-sidebar col-xs-12 col-sm-3">
-  <div id="docSidebar" class="sticky-container">
-    <div role="search" class="sphinx-search">
-  <form id="rtd-search-form" class="wy-form" action="../../../search.html" method="get">
-    <input type="text" name="q" placeholder="Search documentation" class="search-documentation" />
-    <input type="hidden" name="check_keywords" value="yes" />
-    <input type="hidden" name="area" value="default" />
-  </form>
-</div>
-    
-<!-- Note: only works when deployed -->
-<select class="form-control" onchange="if (this.value) window.location.href=this.value">
-    <option
-      value="/develop"
-      selected
-      >
-      Version: develop (latest - mynewt-documentation)
-    </option>
-    <option
-      value="/latest/os/introduction"
-      >
-      Version: master (latest - mynewt-site)
-    </option>
-    <option
-      value="/v1_2_0/os/introduction"
-      >
-      Version: 1.2.0
-    </option>
-    <option
-      value="/v1_1_0/os/introduction">
-      Version: 1.1.0
-    </option>
-    <option
-      value="/v1_0_0/os/introduction">
-      Version: 1.0.0
-    </option>
-    <option
-      value="/v0_9_0/os/introduction">
-      Version: 0_9_0
-    </option>
-</select>
-    <div class="region region-sidebar">
-      <div class="docs-menu">
-      
-        
-        
-            <ul class="current">
-<li class="toctree-l1"><a class="reference internal" href="../../../index.html">Introduction</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../../get_started/index.html">Setup &amp; Get Started</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../../concepts.html">Concepts</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../../tutorials/tutorials.html">Tutorials</a></li>
-<li class="toctree-l1 current"><a class="reference internal" href="../../os_user_guide.html">OS User Guide</a><ul class="current">
-<li class="toctree-l2 current"><a class="reference internal" href="../mynewt_os.html">OS Core</a><ul class="current">
-<li class="toctree-l3"><a class="reference internal" href="../context_switch/context_switch.html">Scheduler</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../cputime/os_cputime.html">CPU Time</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../time/os_time.html">OS Time</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../task/task.html">Task</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../event_queue/event_queue.html">Event Queues</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../semaphore/semaphore.html">Semaphore</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../mutex/mutex.html">Mutex</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../memory_pool/memory_pool.html">Memory Pools</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../heap/heap.html">Heap</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../mbuf/mbuf.html">Mbufs</a></li>
-<li class="toctree-l3 current"><a class="current reference internal" href="#">Msys</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../mqueue/mqueue.html">Mqueue</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../sanity/sanity.html">Sanity</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../callout/callout.html">Callout</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../API.html">API</a></li>
-</ul>
-</li>
-<li class="toctree-l2"><a class="reference internal" href="../porting/port_os.html">Porting Mynewt OS</a></li>
-<li class="toctree-l2"><a class="reference internal" href="../../modules/console/console.html">Console</a></li>
-<li class="toctree-l2"><a class="reference internal" href="../../modules/sysinitconfig/sysinitconfig.html">System Configuration and Initialization</a></li>
-</ul>
-</li>
-<li class="toctree-l1"><a class="reference internal" href="../../../network/ble/ble_intro.html">BLE User Guide</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../../newt/index.html">Newt Tool Guide</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../../newtmgr/index.html">Newt Manager Guide</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../../misc/index.html">Appendix</a></li>
-</ul>
-
-        
-      
-      </div>
-    </div>
-  </div>
-  <!-- ENDS STICKY CONTAINER -->
-</div>
-<!-- ENDS .container-sidebar -->
-
-            <div class="col-xs-12 col-sm-9">
-              <div class="alert alert-info" role="alert">
-  <p>
-    This is the development version of Apache Mynewt documentation. As such it may not be as complete as the latest
-    stable version of the documentation found <a href="/latest/os/introduction/">here</a>.
-  </p>
-  <p>
-    To improve this documentation please visit <a href="https://github.com/apache/mynewt-documentation">https://github.com/apache/mynewt-documentation</a>.
-  </p>
-</div>
-              
-              <div class="">
-                <div class="rst-content">
-                  <div role="main" class="document" itemscope="itemscope" itemtype="http://schema.org/Article">
-                   <div itemprop="articleBody">
-                    
-  <div class="section" id="msys">
-<h1>Msys<a class="headerlink" href="#msys" title="Permalink to this headline">?</a></h1>
-<p>Msys stands for ?system mbufs? and is a set of API built on top of the
-mbuf code. The basic idea behind msys is the following. The developer
-can create different size mbuf pools and register them with msys. The
-application then allocates mbufs using the msys API (as opposed to the
-mbuf API). The msys code will choose the mbuf pool with the smallest
-mbufs that can accommodate the requested size.</p>
-<p>Let us walk through an example where the user registers three mbuf pools
-with msys: one with 32 byte mbufs, one with 256 and one with 2048. If
-the user requests an mbuf with 10 bytes, the 32-byte mbuf pool is used.
-If the request is for 33 bytes the 256 byte mbuf pool is used. If an
-mbuf data size is requested that is larger than any of the pools (say,
-4000 bytes) the largest pool is used. While this behaviour may not be
-optimal in all cases that is the currently implemented behaviour. All
-this means is that the user is not guaranteed that a single mbuf can
-hold the requested data.</p>
-<p>The msys code will not allocate an mbuf from a larger pool if the chosen
-mbuf pool is empty. Similarly, the msys code will not chain together a
-number of smaller mbufs to accommodate the requested size. While this
-behaviour may change in future implementations the current code will
-simply return NULL. Using the above example, say the user requests 250
-bytes. The msys code chooses the appropriate pool (i.e. the 256 byte
-mbuf pool) and attempts to allocate an mbuf from that pool. If that pool
-is empty, NULL is returned even though the 32 and 2048 byte pools are
-not empty.</p>
-<p>Note that no added descriptions on how to use the msys API are presented
-here (other than in the API descriptions themselves) as the msys API is
-used in exactly the same manner as the mbuf API. The only difference is
-that mbuf pools are added to msys by calling <code class="docutils literal notranslate"><span class="pre">os_msys_register().</span></code></p>
-<div class="section" id="api">
-<h2>API<a class="headerlink" href="#api" title="Permalink to this headline">?</a></h2>
-<div class="admonition warning">
-<p class="first admonition-title">Warning</p>
-<p class="last">doxygengroup: Cannot find namespace ?OSMsys? in doxygen xml output for project ?mynewt-core? from directory: mynewt-core-xml</p>
-</div>
-</div>
-</div>
-
-
-                   </div>
-                  </div>
-                  
-    <div class="rst-footer-buttons row" role="navigation" aria-label="footer navigation">
-      
-        <a href="../mqueue/mqueue.html" class="btn btn-neutral float-right" title="Mqueue" accesskey="n">Next: Mqueue <span class="fa fa-arrow-circle-right"></span></a>
-      
-      
-        <a href="../mbuf/mbuf.html" class="btn btn-neutral" title="Mbufs" accesskey="p"><span class="fa fa-arrow-circle-left"></span> Previous: Mbufs</a>
-      
-    </div>
-
-                </div>
-              </div>
-            </div>
-            <!-- ENDS CONTENT SECTION -->
-          </div>
-          <!-- ENDS .content -->
-        </div>
-      </div>
-      <footer>
-  <div class="container">
-    <div class="row">
-      <div class="col-xs-12">
-          
-              <p class="copyright">Apache Mynewt is available under Apache License, version 2.0.</p>
-          
-      </div>
-      <div class="col-xs-12">
-          <div class="logos">
-              <img src="../../../_static/img/asf_logo_wide_small.png" alt="Apache" title="Apache">
-              <small class="footnote">
-                Apache Mynewt, Mynewt, Apache, the Apache feather logo, and the Apache Mynewt project logo are either
-                registered trademarks or trademarks of the Apache Software Foundation in the United States and other countries.
-              </small>
-              <a href="https://join.slack.com/mynewt/shared_invite/MTkwMTg1ODM1NTg5LTE0OTYxNzQ4NzQtZTU1YmNhYjhkMg">
-                <img src="../../../_static/img/add_to_slack.png" alt="Slack Icon" title="Join our Slack Community" />
-              </a>
-          </div>
-      </div>
-    </div>
-  </div>
-</footer>
-    </div>
-    <!-- ENDS #wrapper -->
-
-  
-
-    <script type="text/javascript">
-        var DOCUMENTATION_OPTIONS = {
-            URL_ROOT:'../../../',
-            VERSION:'1.3.0',
-            COLLAPSE_INDEX:false,
-            FILE_SUFFIX:'.html',
-            HAS_SOURCE:  true,
-            SOURCELINK_SUFFIX: '.txt'
-        };
-    </script>
-      <script type="text/javascript" src="../../../_static/jquery.js"></script>
-      <script type="text/javascript" src="../../../_static/underscore.js"></script>
-      <script type="text/javascript" src="../../../_static/doctools.js"></script>
-      <script type="text/javascript" src="../../../_static/js/bootstrap-3.0.3.min.js"></script>
-      <script type="text/javascript" src="../../../_static/js/affix.js"></script>
-      <script type="text/javascript" src="../../../_static/js/main.js"></script>
-
-   
-
-  </body>
-</html>
\ No newline at end of file
diff --git a/develop/os/core_os/mutex/mutex.html b/develop/os/core_os/mutex/mutex.html
index 3a9fbf797..fda80b124 100644
--- a/develop/os/core_os/mutex/mutex.html
+++ b/develop/os/core_os/mutex/mutex.html
@@ -41,9 +41,9 @@
                 href="../../../genindex.html"/>
           <link rel="search" title="Search" href="../../../search.html"/>
       <link rel="top" title="Apache Mynewt 1.3.0 documentation" href="../../../index.html"/>
-          <link rel="up" title="Mynewt Core OS" href="../mynewt_os.html"/>
-          <link rel="next" title="Memory Pools" href="../memory_pool/memory_pool.html"/>
-          <link rel="prev" title="Semaphore" href="../semaphore/semaphore.html"/> 
+          <link rel="up" title="Apache Mynewt Operating System Kernel" href="../mynewt_os.html"/>
+          <link rel="next" title="Semaphore" href="../semaphore/semaphore.html"/>
+          <link rel="prev" title="Task" href="../task/task.html"/> 
 
     
     <script src="../../../_static/js/modernizr.min.js"></script>
@@ -156,7 +156,7 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
     
       <a href="../../os_user_guide.html">OS User Guide</a> /
     
-      <a href="../mynewt_os.html">Mynewt Core OS</a> /
+      <a href="../mynewt_os.html">Apache Mynewt Operating System Kernel</a> /
     
     Mutex
     
@@ -224,27 +224,25 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
 <li class="toctree-l1"><a class="reference internal" href="../../../concepts.html">Concepts</a></li>
 <li class="toctree-l1"><a class="reference internal" href="../../../tutorials/tutorials.html">Tutorials</a></li>
 <li class="toctree-l1 current"><a class="reference internal" href="../../os_user_guide.html">OS User Guide</a><ul class="current">
-<li class="toctree-l2 current"><a class="reference internal" href="../mynewt_os.html">OS Core</a><ul class="current">
+<li class="toctree-l2 current"><a class="reference internal" href="../mynewt_os.html">Kernel</a><ul class="current">
 <li class="toctree-l3"><a class="reference internal" href="../context_switch/context_switch.html">Scheduler</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../cputime/os_cputime.html">CPU Time</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../time/os_time.html">OS Time</a></li>
 <li class="toctree-l3"><a class="reference internal" href="../task/task.html">Task</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../event_queue/event_queue.html">Event Queues</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../semaphore/semaphore.html">Semaphore</a></li>
 <li class="toctree-l3 current"><a class="current reference internal" href="#">Mutex</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../memory_pool/memory_pool.html">Memory Pools</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../semaphore/semaphore.html">Semaphore</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../event_queue/event_queue.html">Event Queues</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../callout/callout.html">Callout</a></li>
 <li class="toctree-l3"><a class="reference internal" href="../heap/heap.html">Heap</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../memory_pool/memory_pool.html">Memory Pools</a></li>
 <li class="toctree-l3"><a class="reference internal" href="../mbuf/mbuf.html">Mbufs</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../msys/msys.html">Msys</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../mqueue/mqueue.html">Mqueue</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../cputime/os_cputime.html">CPU Time</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../time/os_time.html">OS Time</a></li>
 <li class="toctree-l3"><a class="reference internal" href="../sanity/sanity.html">Sanity</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../callout/callout.html">Callout</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../API.html">API</a></li>
 </ul>
 </li>
-<li class="toctree-l2"><a class="reference internal" href="../porting/port_os.html">Porting Mynewt OS</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../../modules/hal/hal.html">Hardware Abstraction</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../porting/port_os.html">Porting Guide</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../../modules/sysinitconfig/sysinitconfig.html">System Configuration</a></li>
 <li class="toctree-l2"><a class="reference internal" href="../../modules/console/console.html">Console</a></li>
-<li class="toctree-l2"><a class="reference internal" href="../../modules/sysinitconfig/sysinitconfig.html">System Configuration and Initialization</a></li>
 </ul>
 </li>
 <li class="toctree-l1"><a class="reference internal" href="../../../network/ble/ble_intro.html">BLE User Guide</a></li>
@@ -294,15 +292,15 @@ <h2>Description<a class="headerlink" href="#description" title="Permalink to thi
 tasks start running in order to avoid a task possibly using the mutex
 before it is initialized.</p>
 <p>When a task wants exclusive access to a shared resource it needs to
-obtain the mutex by calling <em>os_mutex_pend</em>. If the mutex is currently
+obtain the mutex by calling <a class="reference internal" href="#c.os_mutex_pend" title="os_mutex_pend"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_mutex_pend()</span></code></a>. If the mutex is currently
 owned by a different task (a lower priority task), the requesting task
 will be put to sleep and the owners priority will be elevated to the
 priority of the requesting task. Note that multiple tasks can request
 ownership and the current owner is elevated to the highest priority of
 any task waitin on the mutex. When the task is done using the shared
-resource, it needs to release the mutex by called <em>os_mutex_release</em>.
+resource, it needs to release the mutex by called <a class="reference internal" href="#c.os_mutex_release" title="os_mutex_release"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_mutex_release()</span></code></a>.
 There needs to be one release per call to pend. Note that nested calls
-to <em>os_mutex_pend</em> are allowed but there needs to be one release per
+to <a class="reference internal" href="#c.os_mutex_pend" title="os_mutex_pend"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_mutex_pend()</span></code></a> are allowed but there needs to be one release per
 pend.</p>
 <p>The following example will illustrate how priority inheritance works. In
 this example, the task number is the same as its priority. Remember that
@@ -320,67 +318,112 @@ <h2>Description<a class="headerlink" href="#description" title="Permalink to thi
 task, once the mutex is released the highest priority task waiting on
 the mutex is run.</p>
 </div>
-<div class="section" id="data-structures">
-<h2>Data structures<a class="headerlink" href="#data-structures" title="Permalink to this headline">?</a></h2>
-<div class="code c highlight-none notranslate"><div class="highlight"><pre><span></span>struct os_mutex
-{
-    SLIST_HEAD(, os_task) mu_head;
-    uint8_t     _pad;
-    uint8_t     mu_prio;
-    uint16_t    mu_level;
-    struct os_task *mu_owner;
-};
-</pre></div>
-</div>
-<table border="1" class="docutils">
-<colgroup>
-<col width="47%" />
-<col width="53%" />
-</colgroup>
-<thead valign="bottom">
-<tr class="row-odd"><th class="head">Element</th>
-<th class="head">Description</th>
-</tr>
-</thead>
-<tbody valign="top">
-<tr class="row-even"><td>mu_head</td>
-<td>Queue head for
-list of tasks
-waiting on
-mutex</td>
-</tr>
-<tr class="row-odd"><td>_pad</td>
-<td>Padding</td>
-</tr>
-<tr class="row-even"><td>mu_prio</td>
-<td>Default
-priority of
-owner of
-mutex. Used to
-reset priority
-of task when
-mutex released</td>
-</tr>
-<tr class="row-odd"><td>mu_level</td>
-<td>Call nesting
-level (for
-nested calls)</td>
-</tr>
-<tr class="row-even"><td>mu_owner</td>
-<td>Pointer to
-task structure
-which owns
-mutex</td>
-</tr>
-</tbody>
-</table>
-</div>
 <div class="section" id="api">
 <h2>API<a class="headerlink" href="#api" title="Permalink to this headline">?</a></h2>
-<div class="admonition warning">
-<p class="first admonition-title">Warning</p>
-<p class="last">doxygengroup: Cannot find namespace ?OSMutex? in doxygen xml output for project ?mynewt-core? from directory: mynewt-core-xml</p>
+<dl class="variable">
+<dt id="c.os_mutex::_pad">
+<span class="target" id="group___o_s_mutex_1ga57ebc843a2abfdfb150484709f8c918b"></span>uint8_t <code class="descclassname">os_mutex::</code><code class="descname">_pad</code><a class="headerlink" href="#c.os_mutex::_pad" title="Permalink to this definition">?</a></dt>
+<dd></dd></dl>
+
+<dl class="variable">
+<dt id="c.os_mutex::mu_prio">
+<span class="target" id="group___o_s_mutex_1gab11db74bc914d330188ec8cf6b7ccda1"></span>uint8_t <code class="descclassname">os_mutex::</code><code class="descname">mu_prio</code><a class="headerlink" href="#c.os_mutex::mu_prio" title="Permalink to this definition">?</a></dt>
+<dd><p>Mutex owner?s default priority. </p>
+</dd></dl>
+
+<dl class="variable">
+<dt id="c.os_mutex::mu_level">
+<span class="target" id="group___o_s_mutex_1ga3f5cb3a993b3d3ceae9c9a3050cf7e0e"></span>uint16_t <code class="descclassname">os_mutex::</code><code class="descname">mu_level</code><a class="headerlink" href="#c.os_mutex::mu_level" title="Permalink to this definition">?</a></dt>
+<dd><p>Mutex call nesting level. </p>
+</dd></dl>
+
+<dl class="variable">
+<dt id="c.os_mutex::mu_owner">
+<span class="target" id="group___o_s_mutex_1gad7f904991f57f1289b0947da3b3ee339"></span>struct os_task* <code class="descclassname">os_mutex::</code><code class="descname">mu_owner</code><a class="headerlink" href="#c.os_mutex::mu_owner" title="Permalink to this definition">?</a></dt>
+<dd><p>Task that owns the mutex. </p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_mutex::SLIST_HEAD">
+<span class="target" id="group___o_s_mutex_1ga639310579608b2315fdace1a33a51ea7"></span><code class="descclassname">os_mutex::</code><code class="descname">SLIST_HEAD</code><span class="sig-paren">(</span>os_task<span class="sig-paren">)</span><a class="headerlink" href="#c.os_mutex::SLIST_HEAD" title="Permalink to this definition">?</a></dt>
+<dd></dd></dl>
+
+<dl class="function">
+<dt id="c.os_mutex_init">
+<span class="target" id="group___o_s_mutex_1gad40a5e8c7af09d2cbe4bbc1ef88d48dd"></span>os_error_t <code class="descname">os_mutex_init</code><span class="sig-paren">(</span>struct  os_mutex  *<em>&nbsp;mu</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_mutex_init" title="Permalink to this definition">?</a></dt>
+<dd><p>Create a mutex and initialize it. </p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>os_error_t OS_INVALID_PARM Mutex passed in was NULL. OS_OK no error. </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">mu</span></code>: Pointer to mutex</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_mutex_release">
+<span class="target" id="group___o_s_mutex_1ga73b1ca40d62d2e08f6f7bce52e50db30"></span>os_error_t <code class="descname">os_mutex_release</code><span class="sig-paren">(</span>struct  os_mutex  *<em>&nbsp;mu</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_mutex_release" title="Permalink to this definition">?</a></dt>
+<dd><p>Release a mutex. </p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>os_error_t OS_INVALID_PARM Mutex passed in was NULL. OS_BAD_MUTEX Mutex was not granted to current task (not owner). OS_OK No error </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">mu</span></code>: Pointer to the mutex to be released</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_mutex_pend">
+<span class="target" id="group___o_s_mutex_1ga2b28a0d4998fdee4047cf949fed7bab7"></span>os_error_t <code class="descname">os_mutex_pend</code><span class="sig-paren">(</span>struct  os_mutex  *<em>&nbsp;mu</em>, uint32_t<em>&nbsp;timeout</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_mutex_pend" title="Permalink to this definition">?</a></dt>
+<dd><p>Pend (wait) for a mutex. </p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>os_error_t OS_INVALID_PARM Mutex passed in was NULL. OS_TIMEOUT Mutex was owned by another task and timeout=0 OS_OK no error. </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">mu</span></code>: Pointer to mutex. </li>
+<li><code class="docutils literal notranslate"><span class="pre">timeout</span></code>: Timeout, in os ticks. A timeout of 0 means do not wait if not available. A timeout of 0xFFFFFFFF means wait forever.</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="class">
+<dt id="_CPPv38os_mutex">
+<span id="_CPPv28os_mutex"></span><span id="os_mutex"></span><span class="target" id="structos__mutex"></span><em class="property">struct </em><code class="descname">os_mutex</code><a class="headerlink" href="#_CPPv38os_mutex" title="Permalink to this definition">?</a><br /></dt>
+<dd><em>#include &lt;os_mutex.h&gt;</em><p>OS mutex structure. </p>
+<div class="breathe-sectiondef docutils container">
+<p class="breathe-sectiondef-title rubric">Public Members</p>
+<dl class="variable">
+<dt>
+<span class="target" id="group___o_s_mutex_1gab11db74bc914d330188ec8cf6b7ccda1"></span>uint8_t <code class="descname">mu_prio</code></dt>
+<dd><p>Mutex owner?s default priority. </p>
+</dd></dl>
+
+<dl class="variable">
+<dt>
+<span class="target" id="group___o_s_mutex_1ga3f5cb3a993b3d3ceae9c9a3050cf7e0e"></span>uint16_t <code class="descname">mu_level</code></dt>
+<dd><p>Mutex call nesting level. </p>
+</dd></dl>
+
+<dl class="variable">
+<dt>
+<span class="target" id="group___o_s_mutex_1gad7f904991f57f1289b0947da3b3ee339"></span>struct os_task* <code class="descname">mu_owner</code></dt>
+<dd><p>Task that owns the mutex. </p>
+</dd></dl>
+
 </div>
+</dd></dl>
+
 </div>
 </div>
 
@@ -390,10 +433,10 @@ <h2>API<a class="headerlink" href="#api" title="Permalink to this headline">?</
                   
     <div class="rst-footer-buttons row" role="navigation" aria-label="footer navigation">
       
-        <a href="../memory_pool/memory_pool.html" class="btn btn-neutral float-right" title="Memory Pools" accesskey="n">Next: Memory Pools <span class="fa fa-arrow-circle-right"></span></a>
+        <a href="../semaphore/semaphore.html" class="btn btn-neutral float-right" title="Semaphore" accesskey="n">Next: Semaphore <span class="fa fa-arrow-circle-right"></span></a>
       
       
-        <a href="../semaphore/semaphore.html" class="btn btn-neutral" title="Semaphore" accesskey="p"><span class="fa fa-arrow-circle-left"></span> Previous: Semaphore</a>
+        <a href="../task/task.html" class="btn btn-neutral" title="Task" accesskey="p"><span class="fa fa-arrow-circle-left"></span> Previous: Task</a>
       
     </div>
 
diff --git a/develop/os/core_os/mynewt_os.html b/develop/os/core_os/mynewt_os.html
index 8f69050f3..795cb59ac 100644
--- a/develop/os/core_os/mynewt_os.html
+++ b/develop/os/core_os/mynewt_os.html
@@ -10,7 +10,7 @@
     
 
     
-    <title>Mynewt Core OS &mdash; Apache Mynewt 1.3.0 documentation</title>
+    <title>Apache Mynewt Operating System Kernel &mdash; Apache Mynewt 1.3.0 documentation</title>
     
 
     
@@ -156,7 +156,7 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
     
       <a href="../os_user_guide.html">OS User Guide</a> /
     
-    Mynewt Core OS
+    Apache Mynewt Operating System Kernel
     
   <div class="sourcelink">
     <a href="https://github.com/apache/mynewt-core/edit/master/docs/os/core_os/mynewt_os.rst" class="icon icon-github"
@@ -222,27 +222,25 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
 <li class="toctree-l1"><a class="reference internal" href="../../concepts.html">Concepts</a></li>
 <li class="toctree-l1"><a class="reference internal" href="../../tutorials/tutorials.html">Tutorials</a></li>
 <li class="toctree-l1 current"><a class="reference internal" href="../os_user_guide.html">OS User Guide</a><ul class="current">
-<li class="toctree-l2 current"><a class="current reference internal" href="#">OS Core</a><ul>
+<li class="toctree-l2 current"><a class="current reference internal" href="#">Kernel</a><ul>
 <li class="toctree-l3"><a class="reference internal" href="context_switch/context_switch.html">Scheduler</a></li>
-<li class="toctree-l3"><a class="reference internal" href="cputime/os_cputime.html">CPU Time</a></li>
-<li class="toctree-l3"><a class="reference internal" href="time/os_time.html">OS Time</a></li>
 <li class="toctree-l3"><a class="reference internal" href="task/task.html">Task</a></li>
-<li class="toctree-l3"><a class="reference internal" href="event_queue/event_queue.html">Event Queues</a></li>
-<li class="toctree-l3"><a class="reference internal" href="semaphore/semaphore.html">Semaphore</a></li>
 <li class="toctree-l3"><a class="reference internal" href="mutex/mutex.html">Mutex</a></li>
-<li class="toctree-l3"><a class="reference internal" href="memory_pool/memory_pool.html">Memory Pools</a></li>
+<li class="toctree-l3"><a class="reference internal" href="semaphore/semaphore.html">Semaphore</a></li>
+<li class="toctree-l3"><a class="reference internal" href="event_queue/event_queue.html">Event Queues</a></li>
+<li class="toctree-l3"><a class="reference internal" href="callout/callout.html">Callout</a></li>
 <li class="toctree-l3"><a class="reference internal" href="heap/heap.html">Heap</a></li>
+<li class="toctree-l3"><a class="reference internal" href="memory_pool/memory_pool.html">Memory Pools</a></li>
 <li class="toctree-l3"><a class="reference internal" href="mbuf/mbuf.html">Mbufs</a></li>
-<li class="toctree-l3"><a class="reference internal" href="msys/msys.html">Msys</a></li>
-<li class="toctree-l3"><a class="reference internal" href="mqueue/mqueue.html">Mqueue</a></li>
+<li class="toctree-l3"><a class="reference internal" href="cputime/os_cputime.html">CPU Time</a></li>
+<li class="toctree-l3"><a class="reference internal" href="time/os_time.html">OS Time</a></li>
 <li class="toctree-l3"><a class="reference internal" href="sanity/sanity.html">Sanity</a></li>
-<li class="toctree-l3"><a class="reference internal" href="callout/callout.html">Callout</a></li>
-<li class="toctree-l3"><a class="reference internal" href="API.html">API</a></li>
 </ul>
 </li>
-<li class="toctree-l2"><a class="reference internal" href="porting/port_os.html">Porting Mynewt OS</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../modules/hal/hal.html">Hardware Abstraction</a></li>
+<li class="toctree-l2"><a class="reference internal" href="porting/port_os.html">Porting Guide</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../modules/sysinitconfig/sysinitconfig.html">System Configuration</a></li>
 <li class="toctree-l2"><a class="reference internal" href="../modules/console/console.html">Console</a></li>
-<li class="toctree-l2"><a class="reference internal" href="../modules/sysinitconfig/sysinitconfig.html">System Configuration and Initialization</a></li>
 </ul>
 </li>
 <li class="toctree-l1"><a class="reference internal" href="../../network/ble/ble_intro.html">BLE User Guide</a></li>
@@ -276,8 +274,8 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
                   <div role="main" class="document" itemscope="itemscope" itemtype="http://schema.org/Article">
                    <div itemprop="articleBody">
                     
-  <div class="section" id="mynewt-core-os">
-<h1>Mynewt Core OS<a class="headerlink" href="#mynewt-core-os" title="Permalink to this headline">?</a></h1>
+  <div class="section" id="apache-mynewt-operating-system-kernel">
+<h1>Apache Mynewt Operating System Kernel<a class="headerlink" href="#apache-mynewt-operating-system-kernel" title="Permalink to this headline">?</a></h1>
 <div class="toctree-wrapper compound">
 </div>
 <p>The Mynewt Core OS is a multitasking, preemptive real-time operating
@@ -376,15 +374,15 @@ <h2>Example<a class="headerlink" href="#example" title="Permalink to this headli
 queue. The application task initialization function is responsible for
 initializing all the data objects that each task exposes to the other
 tasks. The tasks themselves are also initialized at this time (by
-calling <code class="docutils literal notranslate"><span class="pre">os_task_init()</span></code>).</p>
+calling <a class="reference internal" href="task/task.html#c.os_task_init" title="os_task_init"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_task_init()</span></code></a>).</p>
 <p>In the example, each task works in a ping-pong like fashion: task 1
 wakes up, adds a token to semaphore 1 and then waits for a token from
 semaphore 2. Task 2 waits for a token on semaphore 1 and once it gets
 it, adds a token to semaphore 2. Notice that the semaphores are
 initialized by the application specific task initialization functions
 and not inside the task handler functions. If task 2 (being lower in
-priority than task 1) had called os_sem_init() for task2_sem inside
-task2_handler(), task 1 would have called os_sem_pend() using
+priority than task 1) had called <a class="reference internal" href="semaphore/semaphore.html#c.os_sem_init" title="os_sem_init"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_sem_init()</span></code></a> for task2_sem inside
+task2_handler(), task 1 would have called <a class="reference internal" href="semaphore/semaphore.html#c.os_sem_pend" title="os_sem_pend"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_sem_pend()</span></code></a> using
 task2_sem before task2_sem was initialized.</p>
 <div class="code c highlight-none notranslate"><div class="highlight"><pre><span></span>    struct os_sem task1_sem;
     struct os_sem task2_sem;
diff --git a/develop/os/core_os/os_init.html b/develop/os/core_os/os_init.html
deleted file mode 100644
index 294d1c430..000000000
--- a/develop/os/core_os/os_init.html
+++ /dev/null
@@ -1,335 +0,0 @@
-
-
-<!DOCTYPE html>
-<html lang="en">
-  <head>
-    <meta charset="utf-8">
-    <meta http-equiv="X-UA-Compatible" content="IE=edge">
-    <meta name="viewport" content="width=device-width, initial-scale=1.0">
-
-    
-
-    
-    <title>os_init &mdash; Apache Mynewt 1.3.0 documentation</title>
-    
-
-    
-    
-      <link rel="shortcut icon" href="../../_static/mynewt-logo-only-newt32x32.png"/>
-    
-
-    
-
-    <link rel="stylesheet" href="../../_static/css/theme.css" type="text/css" />
-
-    
-      <link rel="stylesheet" href="../../_static/css/sphinx_theme.css" type="text/css" />
-    
-      <link rel="stylesheet" href="../../_static/css/bootstrap-3.0.3.min.css" type="text/css" />
-    
-      <link rel="stylesheet" href="../../_static/css/v2.css" type="text/css" />
-    
-      <link rel="stylesheet" href="../../_static/css/custom.css" type="text/css" />
-    
-      <link rel="stylesheet" href="../../_static/css/restructuredtext.css" type="text/css" />
-    
-
-    
-
-    <link rel="stylesheet" href="../../_static/css/overrides.css" type="text/css" />
-          <link rel="index" title="Index"
-                href="../../genindex.html"/>
-          <link rel="search" title="Search" href="../../search.html"/>
-      <link rel="top" title="Apache Mynewt 1.3.0 documentation" href="../../index.html"/> 
-
-    
-    <script src="../../_static/js/modernizr.min.js"></script>
-
-    
-    <script>
-    (function(i, s, o, g, r, a, m) {
-	i["GoogleAnalyticsObject"] = r;
-	(i[r] =
-		i[r] ||
-		function() {
-			(i[r].q = i[r].q || []).push(arguments);
-		}),
-		(i[r].l = 1 * new Date());
-	(a = s.createElement(o)), (m = s.getElementsByTagName(o)[0]);
-	a.async = 1;
-	a.src = g;
-	m.parentNode.insertBefore(a, m);
-})(window, document, "script", "//www.google-analytics.com/analytics.js", "ga");
-
-ga("create", "UA-72162311-1", "auto");
-ga("send", "pageview");
-</script>
-    
-
-  </head>
-
-  <body class="not-front page-documentation" role="document" >
-    <div id="wrapper">
-      <div class="container">
-    <div id="banner" class="row v2-main-banner">
-        <a class="logo-cell" href="/">
-            <img class="logo" src="../../_static/img/logo.png">
-        </a>
-        <div class="tagline-cell">
-            <h4 class="tagline">An OS to build, deploy and securely manage billions of devices</h4>
-        </div>
-        <div class="news-cell">
-            <div class="well">
-              <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (December 13, 2017)
-            </div>
-        </div>
-    </div>
-</div>
-      
-<header>
-    <nav id="navbar" class="navbar navbar-inverse" role="navigation">
-        <div class="container">
-            <!-- Collapsed navigation -->
-            <div class="navbar-header">
-                <!-- Expander button -->
-                <button type="button" class="navbar-toggle" data-toggle="collapse" data-target=".navbar-collapse">
-                    <span class="sr-only">Toggle navigation</span>
-                    <span class="icon-bar"></span>
-                    <span class="icon-bar"></span>
-                    <span class="icon-bar"></span>
-                </button>
-
-            </div>
-
-            <!-- Expanded navigation -->
-            <div class="navbar-collapse collapse">
-                <!-- Main navigation -->
-                <ul class="nav navbar-nav navbar-right">
-                    <li>
-                        <a href="/"><i class="fa fa-home" style="font-size: larger;"></i></a>
-                    </li>
-                    <li class="important">
-                        <a href="/get_started/quick_start.html">Quick Start</a>
-                    </li>
-                    <li>
-                        <a href="/about/">About</a>
-                    </li>
-                    <li>
-                        <a href="/talks/">Talks</a>
-                    </li>
-                    <li class="active">
-                        <a href="/documentation/">Documentation</a>
-                    </li>
-                    <li>
-                        <a href="/download/">Download</a>
-                    </li>
-                    <li>
-                        <a href="/community/">Community</a>
-                    </li>
-                    <li>
-                        <a href="/events/">Events</a>
-                    </li>
-                </ul>
-
-                <!-- Search, Navigation and Repo links -->
-                <ul class="nav navbar-nav navbar-right">
-                    
-                </ul>
-            </div>
-        </div>
-    </nav>
-</header>
-      <!-- STARTS MAIN CONTENT -->
-      <div id="main-content">
-        
-
-
-
-
-
-<div id="breadcrumb">
-  <div class="container">
-    <a href="/documentation/">Docs</a> /
-    
-    os_init
-    
-  <div class="sourcelink">
-    <a href="https://github.com/apache/mynewt-core/edit/master/docs/os/core_os/os_init.rst" class="icon icon-github"
-           rel="nofollow"> Edit on GitHub</a>
-</div>
-  </div>
-</div>
-        <!-- STARTS CONTAINER -->
-        <div class="container">
-          <!-- STARTS .content -->
-          <div id="content" class="row">
-            
-            <!-- STARTS .container-sidebar -->
-<div class="container-sidebar col-xs-12 col-sm-3">
-  <div id="docSidebar" class="sticky-container">
-    <div role="search" class="sphinx-search">
-  <form id="rtd-search-form" class="wy-form" action="../../search.html" method="get">
-    <input type="text" name="q" placeholder="Search documentation" class="search-documentation" />
-    <input type="hidden" name="check_keywords" value="yes" />
-    <input type="hidden" name="area" value="default" />
-  </form>
-</div>
-    
-<!-- Note: only works when deployed -->
-<select class="form-control" onchange="if (this.value) window.location.href=this.value">
-    <option
-      value="/develop"
-      selected
-      >
-      Version: develop (latest - mynewt-documentation)
-    </option>
-    <option
-      value="/latest/os/introduction"
-      >
-      Version: master (latest - mynewt-site)
-    </option>
-    <option
-      value="/v1_2_0/os/introduction"
-      >
-      Version: 1.2.0
-    </option>
-    <option
-      value="/v1_1_0/os/introduction">
-      Version: 1.1.0
-    </option>
-    <option
-      value="/v1_0_0/os/introduction">
-      Version: 1.0.0
-    </option>
-    <option
-      value="/v0_9_0/os/introduction">
-      Version: 0_9_0
-    </option>
-</select>
-    <div class="region region-sidebar">
-      <div class="docs-menu">
-      
-        
-        
-            <ul>
-<li class="toctree-l1"><a class="reference internal" href="../../index.html">Introduction</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../get_started/index.html">Setup &amp; Get Started</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../concepts.html">Concepts</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../tutorials/tutorials.html">Tutorials</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../os_user_guide.html">OS User Guide</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../network/ble/ble_intro.html">BLE User Guide</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../newt/index.html">Newt Tool Guide</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../newtmgr/index.html">Newt Manager Guide</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../misc/index.html">Appendix</a></li>
-</ul>
-
-        
-      
-      </div>
-    </div>
-  </div>
-  <!-- ENDS STICKY CONTAINER -->
-</div>
-<!-- ENDS .container-sidebar -->
-
-            <div class="col-xs-12 col-sm-9">
-              <div class="alert alert-info" role="alert">
-  <p>
-    This is the development version of Apache Mynewt documentation. As such it may not be as complete as the latest
-    stable version of the documentation found <a href="/latest/os/introduction/">here</a>.
-  </p>
-  <p>
-    To improve this documentation please visit <a href="https://github.com/apache/mynewt-documentation">https://github.com/apache/mynewt-documentation</a>.
-  </p>
-</div>
-              
-              <div class="">
-                <div class="rst-content">
-                  <div role="main" class="document" itemscope="itemscope" itemtype="http://schema.org/Article">
-                   <div itemprop="articleBody">
-                    
-  <div class="section" id="os-init">
-<h1>os_init<a class="headerlink" href="#os-init" title="Permalink to this headline">?</a></h1>
-<div class="highlight-console notranslate"><div class="highlight"><pre><span></span><span class="go">void os_init(void)</span>
-</pre></div>
-</div>
-<p>Initializes the OS. Must be called before the OS is started (i.e.
-os_start() is called).</p>
-<div class="section" id="arguments">
-<h2>Arguments<a class="headerlink" href="#arguments" title="Permalink to this headline">?</a></h2>
-<p>None</p>
-</div>
-<div class="section" id="returned-values">
-<h2>Returned values<a class="headerlink" href="#returned-values" title="Permalink to this headline">?</a></h2>
-<p>None</p>
-</div>
-<div class="section" id="notes">
-<h2>Notes<a class="headerlink" href="#notes" title="Permalink to this headline">?</a></h2>
-<p>The call to os_init performs architecture and bsp initializations and
-initializes the idle task.</p>
-<p>This function does not start the OS, the OS time tick interrupt, or the
-scheduler.</p>
-</div>
-</div>
-
-
-                   </div>
-                  </div>
-                  
-                </div>
-              </div>
-            </div>
-            <!-- ENDS CONTENT SECTION -->
-          </div>
-          <!-- ENDS .content -->
-        </div>
-      </div>
-      <footer>
-  <div class="container">
-    <div class="row">
-      <div class="col-xs-12">
-          
-              <p class="copyright">Apache Mynewt is available under Apache License, version 2.0.</p>
-          
-      </div>
-      <div class="col-xs-12">
-          <div class="logos">
-              <img src="../../_static/img/asf_logo_wide_small.png" alt="Apache" title="Apache">
-              <small class="footnote">
-                Apache Mynewt, Mynewt, Apache, the Apache feather logo, and the Apache Mynewt project logo are either
-                registered trademarks or trademarks of the Apache Software Foundation in the United States and other countries.
-              </small>
-              <a href="https://join.slack.com/mynewt/shared_invite/MTkwMTg1ODM1NTg5LTE0OTYxNzQ4NzQtZTU1YmNhYjhkMg">
-                <img src="../../_static/img/add_to_slack.png" alt="Slack Icon" title="Join our Slack Community" />
-              </a>
-          </div>
-      </div>
-    </div>
-  </div>
-</footer>
-    </div>
-    <!-- ENDS #wrapper -->
-
-  
-
-    <script type="text/javascript">
-        var DOCUMENTATION_OPTIONS = {
-            URL_ROOT:'../../',
-            VERSION:'1.3.0',
-            COLLAPSE_INDEX:false,
-            FILE_SUFFIX:'.html',
-            HAS_SOURCE:  true,
-            SOURCELINK_SUFFIX: '.txt'
-        };
-    </script>
-      <script type="text/javascript" src="../../_static/jquery.js"></script>
-      <script type="text/javascript" src="../../_static/underscore.js"></script>
-      <script type="text/javascript" src="../../_static/doctools.js"></script>
-      <script type="text/javascript" src="../../_static/js/bootstrap-3.0.3.min.js"></script>
-      <script type="text/javascript" src="../../_static/js/affix.js"></script>
-      <script type="text/javascript" src="../../_static/js/main.js"></script>
-
-   
-
-  </body>
-</html>
\ No newline at end of file
diff --git a/develop/os/core_os/os_start.html b/develop/os/core_os/os_start.html
deleted file mode 100644
index 1403042af..000000000
--- a/develop/os/core_os/os_start.html
+++ /dev/null
@@ -1,334 +0,0 @@
-
-
-<!DOCTYPE html>
-<html lang="en">
-  <head>
-    <meta charset="utf-8">
-    <meta http-equiv="X-UA-Compatible" content="IE=edge">
-    <meta name="viewport" content="width=device-width, initial-scale=1.0">
-
-    
-
-    
-    <title>os_start &mdash; Apache Mynewt 1.3.0 documentation</title>
-    
-
-    
-    
-      <link rel="shortcut icon" href="../../_static/mynewt-logo-only-newt32x32.png"/>
-    
-
-    
-
-    <link rel="stylesheet" href="../../_static/css/theme.css" type="text/css" />
-
-    
-      <link rel="stylesheet" href="../../_static/css/sphinx_theme.css" type="text/css" />
-    
-      <link rel="stylesheet" href="../../_static/css/bootstrap-3.0.3.min.css" type="text/css" />
-    
-      <link rel="stylesheet" href="../../_static/css/v2.css" type="text/css" />
-    
-      <link rel="stylesheet" href="../../_static/css/custom.css" type="text/css" />
-    
-      <link rel="stylesheet" href="../../_static/css/restructuredtext.css" type="text/css" />
-    
-
-    
-
-    <link rel="stylesheet" href="../../_static/css/overrides.css" type="text/css" />
-          <link rel="index" title="Index"
-                href="../../genindex.html"/>
-          <link rel="search" title="Search" href="../../search.html"/>
-      <link rel="top" title="Apache Mynewt 1.3.0 documentation" href="../../index.html"/> 
-
-    
-    <script src="../../_static/js/modernizr.min.js"></script>
-
-    
-    <script>
-    (function(i, s, o, g, r, a, m) {
-	i["GoogleAnalyticsObject"] = r;
-	(i[r] =
-		i[r] ||
-		function() {
-			(i[r].q = i[r].q || []).push(arguments);
-		}),
-		(i[r].l = 1 * new Date());
-	(a = s.createElement(o)), (m = s.getElementsByTagName(o)[0]);
-	a.async = 1;
-	a.src = g;
-	m.parentNode.insertBefore(a, m);
-})(window, document, "script", "//www.google-analytics.com/analytics.js", "ga");
-
-ga("create", "UA-72162311-1", "auto");
-ga("send", "pageview");
-</script>
-    
-
-  </head>
-
-  <body class="not-front page-documentation" role="document" >
-    <div id="wrapper">
-      <div class="container">
-    <div id="banner" class="row v2-main-banner">
-        <a class="logo-cell" href="/">
-            <img class="logo" src="../../_static/img/logo.png">
-        </a>
-        <div class="tagline-cell">
-            <h4 class="tagline">An OS to build, deploy and securely manage billions of devices</h4>
-        </div>
-        <div class="news-cell">
-            <div class="well">
-              <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (December 13, 2017)
-            </div>
-        </div>
-    </div>
-</div>
-      
-<header>
-    <nav id="navbar" class="navbar navbar-inverse" role="navigation">
-        <div class="container">
-            <!-- Collapsed navigation -->
-            <div class="navbar-header">
-                <!-- Expander button -->
-                <button type="button" class="navbar-toggle" data-toggle="collapse" data-target=".navbar-collapse">
-                    <span class="sr-only">Toggle navigation</span>
-                    <span class="icon-bar"></span>
-                    <span class="icon-bar"></span>
-                    <span class="icon-bar"></span>
-                </button>
-
-            </div>
-
-            <!-- Expanded navigation -->
-            <div class="navbar-collapse collapse">
-                <!-- Main navigation -->
-                <ul class="nav navbar-nav navbar-right">
-                    <li>
-                        <a href="/"><i class="fa fa-home" style="font-size: larger;"></i></a>
-                    </li>
-                    <li class="important">
-                        <a href="/get_started/quick_start.html">Quick Start</a>
-                    </li>
-                    <li>
-                        <a href="/about/">About</a>
-                    </li>
-                    <li>
-                        <a href="/talks/">Talks</a>
-                    </li>
-                    <li class="active">
-                        <a href="/documentation/">Documentation</a>
-                    </li>
-                    <li>
-                        <a href="/download/">Download</a>
-                    </li>
-                    <li>
-                        <a href="/community/">Community</a>
-                    </li>
-                    <li>
-                        <a href="/events/">Events</a>
-                    </li>
-                </ul>
-
-                <!-- Search, Navigation and Repo links -->
-                <ul class="nav navbar-nav navbar-right">
-                    
-                </ul>
-            </div>
-        </div>
-    </nav>
-</header>
-      <!-- STARTS MAIN CONTENT -->
-      <div id="main-content">
-        
-
-
-
-
-
-<div id="breadcrumb">
-  <div class="container">
-    <a href="/documentation/">Docs</a> /
-    
-    os_start
-    
-  <div class="sourcelink">
-    <a href="https://github.com/apache/mynewt-core/edit/master/docs/os/core_os/os_start.rst" class="icon icon-github"
-           rel="nofollow"> Edit on GitHub</a>
-</div>
-  </div>
-</div>
-        <!-- STARTS CONTAINER -->
-        <div class="container">
-          <!-- STARTS .content -->
-          <div id="content" class="row">
-            
-            <!-- STARTS .container-sidebar -->
-<div class="container-sidebar col-xs-12 col-sm-3">
-  <div id="docSidebar" class="sticky-container">
-    <div role="search" class="sphinx-search">
-  <form id="rtd-search-form" class="wy-form" action="../../search.html" method="get">
-    <input type="text" name="q" placeholder="Search documentation" class="search-documentation" />
-    <input type="hidden" name="check_keywords" value="yes" />
-    <input type="hidden" name="area" value="default" />
-  </form>
-</div>
-    
-<!-- Note: only works when deployed -->
-<select class="form-control" onchange="if (this.value) window.location.href=this.value">
-    <option
-      value="/develop"
-      selected
-      >
-      Version: develop (latest - mynewt-documentation)
-    </option>
-    <option
-      value="/latest/os/introduction"
-      >
-      Version: master (latest - mynewt-site)
-    </option>
-    <option
-      value="/v1_2_0/os/introduction"
-      >
-      Version: 1.2.0
-    </option>
-    <option
-      value="/v1_1_0/os/introduction">
-      Version: 1.1.0
-    </option>
-    <option
-      value="/v1_0_0/os/introduction">
-      Version: 1.0.0
-    </option>
-    <option
-      value="/v0_9_0/os/introduction">
-      Version: 0_9_0
-    </option>
-</select>
-    <div class="region region-sidebar">
-      <div class="docs-menu">
-      
-        
-        
-            <ul>
-<li class="toctree-l1"><a class="reference internal" href="../../index.html">Introduction</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../get_started/index.html">Setup &amp; Get Started</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../concepts.html">Concepts</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../tutorials/tutorials.html">Tutorials</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../os_user_guide.html">OS User Guide</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../network/ble/ble_intro.html">BLE User Guide</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../newt/index.html">Newt Tool Guide</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../newtmgr/index.html">Newt Manager Guide</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../misc/index.html">Appendix</a></li>
-</ul>
-
-        
-      
-      </div>
-    </div>
-  </div>
-  <!-- ENDS STICKY CONTAINER -->
-</div>
-<!-- ENDS .container-sidebar -->
-
-            <div class="col-xs-12 col-sm-9">
-              <div class="alert alert-info" role="alert">
-  <p>
-    This is the development version of Apache Mynewt documentation. As such it may not be as complete as the latest
-    stable version of the documentation found <a href="/latest/os/introduction/">here</a>.
-  </p>
-  <p>
-    To improve this documentation please visit <a href="https://github.com/apache/mynewt-documentation">https://github.com/apache/mynewt-documentation</a>.
-  </p>
-</div>
-              
-              <div class="">
-                <div class="rst-content">
-                  <div role="main" class="document" itemscope="itemscope" itemtype="http://schema.org/Article">
-                   <div itemprop="articleBody">
-                    
-  <div class="section" id="os-start">
-<h1>os_start<a class="headerlink" href="#os-start" title="Permalink to this headline">?</a></h1>
-<div class="highlight-console notranslate"><div class="highlight"><pre><span></span><span class="go">void os_start(void)</span>
-</pre></div>
-</div>
-<p>Starts the OS by initializing and enabling the OS time tick and starting
-the scheduler.</p>
-<p>This function does not return.</p>
-<div class="section" id="arguments">
-<h2>Arguments<a class="headerlink" href="#arguments" title="Permalink to this headline">?</a></h2>
-<p>None</p>
-</div>
-<div class="section" id="returned-values">
-<h2>Returned values<a class="headerlink" href="#returned-values" title="Permalink to this headline">?</a></h2>
-<p>None (does not return).</p>
-</div>
-<div class="section" id="notes">
-<h2>Notes<a class="headerlink" href="#notes" title="Permalink to this headline">?</a></h2>
-<p>Once os_start has been called, context is switched to the highest
-priority task that was initialized prior to calling os_start.</p>
-</div>
-</div>
-
-
-                   </div>
-                  </div>
-                  
-                </div>
-              </div>
-            </div>
-            <!-- ENDS CONTENT SECTION -->
-          </div>
-          <!-- ENDS .content -->
-        </div>
-      </div>
-      <footer>
-  <div class="container">
-    <div class="row">
-      <div class="col-xs-12">
-          
-              <p class="copyright">Apache Mynewt is available under Apache License, version 2.0.</p>
-          
-      </div>
-      <div class="col-xs-12">
-          <div class="logos">
-              <img src="../../_static/img/asf_logo_wide_small.png" alt="Apache" title="Apache">
-              <small class="footnote">
-                Apache Mynewt, Mynewt, Apache, the Apache feather logo, and the Apache Mynewt project logo are either
-                registered trademarks or trademarks of the Apache Software Foundation in the United States and other countries.
-              </small>
-              <a href="https://join.slack.com/mynewt/shared_invite/MTkwMTg1ODM1NTg5LTE0OTYxNzQ4NzQtZTU1YmNhYjhkMg">
-                <img src="../../_static/img/add_to_slack.png" alt="Slack Icon" title="Join our Slack Community" />
-              </a>
-          </div>
-      </div>
-    </div>
-  </div>
-</footer>
-    </div>
-    <!-- ENDS #wrapper -->
-
-  
-
-    <script type="text/javascript">
-        var DOCUMENTATION_OPTIONS = {
-            URL_ROOT:'../../',
-            VERSION:'1.3.0',
-            COLLAPSE_INDEX:false,
-            FILE_SUFFIX:'.html',
-            HAS_SOURCE:  true,
-            SOURCELINK_SUFFIX: '.txt'
-        };
-    </script>
-      <script type="text/javascript" src="../../_static/jquery.js"></script>
-      <script type="text/javascript" src="../../_static/underscore.js"></script>
-      <script type="text/javascript" src="../../_static/doctools.js"></script>
-      <script type="text/javascript" src="../../_static/js/bootstrap-3.0.3.min.js"></script>
-      <script type="text/javascript" src="../../_static/js/affix.js"></script>
-      <script type="text/javascript" src="../../_static/js/main.js"></script>
-
-   
-
-  </body>
-</html>
\ No newline at end of file
diff --git a/develop/os/core_os/os_started.html b/develop/os/core_os/os_started.html
deleted file mode 100644
index 802a36c58..000000000
--- a/develop/os/core_os/os_started.html
+++ /dev/null
@@ -1,328 +0,0 @@
-
-
-<!DOCTYPE html>
-<html lang="en">
-  <head>
-    <meta charset="utf-8">
-    <meta http-equiv="X-UA-Compatible" content="IE=edge">
-    <meta name="viewport" content="width=device-width, initial-scale=1.0">
-
-    
-
-    
-    <title>os_started &mdash; Apache Mynewt 1.3.0 documentation</title>
-    
-
-    
-    
-      <link rel="shortcut icon" href="../../_static/mynewt-logo-only-newt32x32.png"/>
-    
-
-    
-
-    <link rel="stylesheet" href="../../_static/css/theme.css" type="text/css" />
-
-    
-      <link rel="stylesheet" href="../../_static/css/sphinx_theme.css" type="text/css" />
-    
-      <link rel="stylesheet" href="../../_static/css/bootstrap-3.0.3.min.css" type="text/css" />
-    
-      <link rel="stylesheet" href="../../_static/css/v2.css" type="text/css" />
-    
-      <link rel="stylesheet" href="../../_static/css/custom.css" type="text/css" />
-    
-      <link rel="stylesheet" href="../../_static/css/restructuredtext.css" type="text/css" />
-    
-
-    
-
-    <link rel="stylesheet" href="../../_static/css/overrides.css" type="text/css" />
-          <link rel="index" title="Index"
-                href="../../genindex.html"/>
-          <link rel="search" title="Search" href="../../search.html"/>
-      <link rel="top" title="Apache Mynewt 1.3.0 documentation" href="../../index.html"/> 
-
-    
-    <script src="../../_static/js/modernizr.min.js"></script>
-
-    
-    <script>
-    (function(i, s, o, g, r, a, m) {
-	i["GoogleAnalyticsObject"] = r;
-	(i[r] =
-		i[r] ||
-		function() {
-			(i[r].q = i[r].q || []).push(arguments);
-		}),
-		(i[r].l = 1 * new Date());
-	(a = s.createElement(o)), (m = s.getElementsByTagName(o)[0]);
-	a.async = 1;
-	a.src = g;
-	m.parentNode.insertBefore(a, m);
-})(window, document, "script", "//www.google-analytics.com/analytics.js", "ga");
-
-ga("create", "UA-72162311-1", "auto");
-ga("send", "pageview");
-</script>
-    
-
-  </head>
-
-  <body class="not-front page-documentation" role="document" >
-    <div id="wrapper">
-      <div class="container">
-    <div id="banner" class="row v2-main-banner">
-        <a class="logo-cell" href="/">
-            <img class="logo" src="../../_static/img/logo.png">
-        </a>
-        <div class="tagline-cell">
-            <h4 class="tagline">An OS to build, deploy and securely manage billions of devices</h4>
-        </div>
-        <div class="news-cell">
-            <div class="well">
-              <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (December 13, 2017)
-            </div>
-        </div>
-    </div>
-</div>
-      
-<header>
-    <nav id="navbar" class="navbar navbar-inverse" role="navigation">
-        <div class="container">
-            <!-- Collapsed navigation -->
-            <div class="navbar-header">
-                <!-- Expander button -->
-                <button type="button" class="navbar-toggle" data-toggle="collapse" data-target=".navbar-collapse">
-                    <span class="sr-only">Toggle navigation</span>
-                    <span class="icon-bar"></span>
-                    <span class="icon-bar"></span>
-                    <span class="icon-bar"></span>
-                </button>
-
-            </div>
-
-            <!-- Expanded navigation -->
-            <div class="navbar-collapse collapse">
-                <!-- Main navigation -->
-                <ul class="nav navbar-nav navbar-right">
-                    <li>
-                        <a href="/"><i class="fa fa-home" style="font-size: larger;"></i></a>
-                    </li>
-                    <li class="important">
-                        <a href="/get_started/quick_start.html">Quick Start</a>
-                    </li>
-                    <li>
-                        <a href="/about/">About</a>
-                    </li>
-                    <li>
-                        <a href="/talks/">Talks</a>
-                    </li>
-                    <li class="active">
-                        <a href="/documentation/">Documentation</a>
-                    </li>
-                    <li>
-                        <a href="/download/">Download</a>
-                    </li>
-                    <li>
-                        <a href="/community/">Community</a>
-                    </li>
-                    <li>
-                        <a href="/events/">Events</a>
-                    </li>
-                </ul>
-
-                <!-- Search, Navigation and Repo links -->
-                <ul class="nav navbar-nav navbar-right">
-                    
-                </ul>
-            </div>
-        </div>
-    </nav>
-</header>
-      <!-- STARTS MAIN CONTENT -->
-      <div id="main-content">
-        
-
-
-
-
-
-<div id="breadcrumb">
-  <div class="container">
-    <a href="/documentation/">Docs</a> /
-    
-    os_started
-    
-  <div class="sourcelink">
-    <a href="https://github.com/apache/mynewt-core/edit/master/docs/os/core_os/os_started.rst" class="icon icon-github"
-           rel="nofollow"> Edit on GitHub</a>
-</div>
-  </div>
-</div>
-        <!-- STARTS CONTAINER -->
-        <div class="container">
-          <!-- STARTS .content -->
-          <div id="content" class="row">
-            
-            <!-- STARTS .container-sidebar -->
-<div class="container-sidebar col-xs-12 col-sm-3">
-  <div id="docSidebar" class="sticky-container">
-    <div role="search" class="sphinx-search">
-  <form id="rtd-search-form" class="wy-form" action="../../search.html" method="get">
-    <input type="text" name="q" placeholder="Search documentation" class="search-documentation" />
-    <input type="hidden" name="check_keywords" value="yes" />
-    <input type="hidden" name="area" value="default" />
-  </form>
-</div>
-    
-<!-- Note: only works when deployed -->
-<select class="form-control" onchange="if (this.value) window.location.href=this.value">
-    <option
-      value="/develop"
-      selected
-      >
-      Version: develop (latest - mynewt-documentation)
-    </option>
-    <option
-      value="/latest/os/introduction"
-      >
-      Version: master (latest - mynewt-site)
-    </option>
-    <option
-      value="/v1_2_0/os/introduction"
-      >
-      Version: 1.2.0
-    </option>
-    <option
-      value="/v1_1_0/os/introduction">
-      Version: 1.1.0
-    </option>
-    <option
-      value="/v1_0_0/os/introduction">
-      Version: 1.0.0
-    </option>
-    <option
-      value="/v0_9_0/os/introduction">
-      Version: 0_9_0
-    </option>
-</select>
-    <div class="region region-sidebar">
-      <div class="docs-menu">
-      
-        
-        
-            <ul>
-<li class="toctree-l1"><a class="reference internal" href="../../index.html">Introduction</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../get_started/index.html">Setup &amp; Get Started</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../concepts.html">Concepts</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../tutorials/tutorials.html">Tutorials</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../os_user_guide.html">OS User Guide</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../network/ble/ble_intro.html">BLE User Guide</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../newt/index.html">Newt Tool Guide</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../newtmgr/index.html">Newt Manager Guide</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../misc/index.html">Appendix</a></li>
-</ul>
-
-        
-      
-      </div>
-    </div>
-  </div>
-  <!-- ENDS STICKY CONTAINER -->
-</div>
-<!-- ENDS .container-sidebar -->
-
-            <div class="col-xs-12 col-sm-9">
-              <div class="alert alert-info" role="alert">
-  <p>
-    This is the development version of Apache Mynewt documentation. As such it may not be as complete as the latest
-    stable version of the documentation found <a href="/latest/os/introduction/">here</a>.
-  </p>
-  <p>
-    To improve this documentation please visit <a href="https://github.com/apache/mynewt-documentation">https://github.com/apache/mynewt-documentation</a>.
-  </p>
-</div>
-              
-              <div class="">
-                <div class="rst-content">
-                  <div role="main" class="document" itemscope="itemscope" itemtype="http://schema.org/Article">
-                   <div itemprop="articleBody">
-                    
-  <div class="section" id="os-started">
-<h1>os_started<a class="headerlink" href="#os-started" title="Permalink to this headline">?</a></h1>
-<div class="highlight-console notranslate"><div class="highlight"><pre><span></span><span class="go">int os_started(void)</span>
-</pre></div>
-</div>
-<p>Returns ?true? (1) if the os has been started; 0 otherwise.</p>
-<div class="section" id="arguments">
-<h2>Arguments<a class="headerlink" href="#arguments" title="Permalink to this headline">?</a></h2>
-<p>None</p>
-</div>
-<div class="section" id="returned-values">
-<h2>Returned values<a class="headerlink" href="#returned-values" title="Permalink to this headline">?</a></h2>
-<p>Integer value with 0 meaning the OS has not been started and 1
-indicating the OS has been started (i.e. os_start() has been called).</p>
-</div>
-</div>
-
-
-                   </div>
-                  </div>
-                  
-                </div>
-              </div>
-            </div>
-            <!-- ENDS CONTENT SECTION -->
-          </div>
-          <!-- ENDS .content -->
-        </div>
-      </div>
-      <footer>
-  <div class="container">
-    <div class="row">
-      <div class="col-xs-12">
-          
-              <p class="copyright">Apache Mynewt is available under Apache License, version 2.0.</p>
-          
-      </div>
-      <div class="col-xs-12">
-          <div class="logos">
-              <img src="../../_static/img/asf_logo_wide_small.png" alt="Apache" title="Apache">
-              <small class="footnote">
-                Apache Mynewt, Mynewt, Apache, the Apache feather logo, and the Apache Mynewt project logo are either
-                registered trademarks or trademarks of the Apache Software Foundation in the United States and other countries.
-              </small>
-              <a href="https://join.slack.com/mynewt/shared_invite/MTkwMTg1ODM1NTg5LTE0OTYxNzQ4NzQtZTU1YmNhYjhkMg">
-                <img src="../../_static/img/add_to_slack.png" alt="Slack Icon" title="Join our Slack Community" />
-              </a>
-          </div>
-      </div>
-    </div>
-  </div>
-</footer>
-    </div>
-    <!-- ENDS #wrapper -->
-
-  
-
-    <script type="text/javascript">
-        var DOCUMENTATION_OPTIONS = {
-            URL_ROOT:'../../',
-            VERSION:'1.3.0',
-            COLLAPSE_INDEX:false,
-            FILE_SUFFIX:'.html',
-            HAS_SOURCE:  true,
-            SOURCELINK_SUFFIX: '.txt'
-        };
-    </script>
-      <script type="text/javascript" src="../../_static/jquery.js"></script>
-      <script type="text/javascript" src="../../_static/underscore.js"></script>
-      <script type="text/javascript" src="../../_static/doctools.js"></script>
-      <script type="text/javascript" src="../../_static/js/bootstrap-3.0.3.min.js"></script>
-      <script type="text/javascript" src="../../_static/js/affix.js"></script>
-      <script type="text/javascript" src="../../_static/js/main.js"></script>
-
-   
-
-  </body>
-</html>
\ No newline at end of file
diff --git a/develop/os/core_os/porting/port_bsp.html b/develop/os/core_os/porting/port_bsp.html
index 25fbc9189..0ba68b222 100644
--- a/develop/os/core_os/porting/port_bsp.html
+++ b/develop/os/core_os/porting/port_bsp.html
@@ -224,15 +224,16 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
 <li class="toctree-l1"><a class="reference internal" href="../../../concepts.html">Concepts</a></li>
 <li class="toctree-l1"><a class="reference internal" href="../../../tutorials/tutorials.html">Tutorials</a></li>
 <li class="toctree-l1 current"><a class="reference internal" href="../../os_user_guide.html">OS User Guide</a><ul class="current">
-<li class="toctree-l2"><a class="reference internal" href="../mynewt_os.html">OS Core</a></li>
-<li class="toctree-l2 current"><a class="reference internal" href="port_os.html">Porting Mynewt OS</a><ul class="current">
+<li class="toctree-l2"><a class="reference internal" href="../mynewt_os.html">Kernel</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../../modules/hal/hal.html">Hardware Abstraction</a></li>
+<li class="toctree-l2 current"><a class="reference internal" href="port_os.html">Porting Guide</a><ul class="current">
 <li class="toctree-l3 current"><a class="current reference internal" href="#">BSP Porting</a></li>
 <li class="toctree-l3"><a class="reference internal" href="port_mcu.html">Porting Mynewt to a new MCU</a></li>
 <li class="toctree-l3"><a class="reference internal" href="port_cpu.html">Porting Mynewt to a new CPU Architecture</a></li>
 </ul>
 </li>
+<li class="toctree-l2"><a class="reference internal" href="../../modules/sysinitconfig/sysinitconfig.html">System Configuration</a></li>
 <li class="toctree-l2"><a class="reference internal" href="../../modules/console/console.html">Console</a></li>
-<li class="toctree-l2"><a class="reference internal" href="../../modules/sysinitconfig/sysinitconfig.html">System Configuration and Initialization</a></li>
 </ul>
 </li>
 <li class="toctree-l1"><a class="reference internal" href="../../../network/ble/ble_intro.html">BLE User Guide</a></li>
diff --git a/develop/os/core_os/porting/port_cpu.html b/develop/os/core_os/porting/port_cpu.html
index 29b8764ad..24c37f5e2 100644
--- a/develop/os/core_os/porting/port_cpu.html
+++ b/develop/os/core_os/porting/port_cpu.html
@@ -42,7 +42,7 @@
           <link rel="search" title="Search" href="../../../search.html"/>
       <link rel="top" title="Apache Mynewt 1.3.0 documentation" href="../../../index.html"/>
           <link rel="up" title="Porting Mynewt OS" href="port_os.html"/>
-          <link rel="next" title="Console" href="../../modules/console/console.html"/>
+          <link rel="next" title="System Configuration and Initialization" href="../../modules/sysinitconfig/sysinitconfig.html"/>
           <link rel="prev" title="Porting Mynewt to a new MCU" href="port_mcu.html"/> 
 
     
@@ -224,15 +224,16 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
 <li class="toctree-l1"><a class="reference internal" href="../../../concepts.html">Concepts</a></li>
 <li class="toctree-l1"><a class="reference internal" href="../../../tutorials/tutorials.html">Tutorials</a></li>
 <li class="toctree-l1 current"><a class="reference internal" href="../../os_user_guide.html">OS User Guide</a><ul class="current">
-<li class="toctree-l2"><a class="reference internal" href="../mynewt_os.html">OS Core</a></li>
-<li class="toctree-l2 current"><a class="reference internal" href="port_os.html">Porting Mynewt OS</a><ul class="current">
+<li class="toctree-l2"><a class="reference internal" href="../mynewt_os.html">Kernel</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../../modules/hal/hal.html">Hardware Abstraction</a></li>
+<li class="toctree-l2 current"><a class="reference internal" href="port_os.html">Porting Guide</a><ul class="current">
 <li class="toctree-l3"><a class="reference internal" href="port_bsp.html">BSP Porting</a></li>
 <li class="toctree-l3"><a class="reference internal" href="port_mcu.html">Porting Mynewt to a new MCU</a></li>
 <li class="toctree-l3 current"><a class="current reference internal" href="#">Porting Mynewt to a new CPU Architecture</a></li>
 </ul>
 </li>
+<li class="toctree-l2"><a class="reference internal" href="../../modules/sysinitconfig/sysinitconfig.html">System Configuration</a></li>
 <li class="toctree-l2"><a class="reference internal" href="../../modules/console/console.html">Console</a></li>
-<li class="toctree-l2"><a class="reference internal" href="../../modules/sysinitconfig/sysinitconfig.html">System Configuration and Initialization</a></li>
 </ul>
 </li>
 <li class="toctree-l1"><a class="reference internal" href="../../../network/ble/ble_intro.html">BLE User Guide</a></li>
@@ -323,7 +324,7 @@ <h2>Implement Architecture-specific OS code<a class="headerlink" href="#implemen
                   
     <div class="rst-footer-buttons row" role="navigation" aria-label="footer navigation">
       
-        <a href="../../modules/console/console.html" class="btn btn-neutral float-right" title="Console" accesskey="n">Next: Console <span class="fa fa-arrow-circle-right"></span></a>
+        <a href="../../modules/sysinitconfig/sysinitconfig.html" class="btn btn-neutral float-right" title="System Configuration and Initialization" accesskey="n">Next: System Configuration and Initialization <span class="fa fa-arrow-circle-right"></span></a>
       
       
         <a href="port_mcu.html" class="btn btn-neutral" title="Porting Mynewt to a new MCU" accesskey="p"><span class="fa fa-arrow-circle-left"></span> Previous: Porting Mynewt to a new MCU</a>
diff --git a/develop/os/core_os/porting/port_mcu.html b/develop/os/core_os/porting/port_mcu.html
index 9f7787852..2ce63ffef 100644
--- a/develop/os/core_os/porting/port_mcu.html
+++ b/develop/os/core_os/porting/port_mcu.html
@@ -224,15 +224,16 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
 <li class="toctree-l1"><a class="reference internal" href="../../../concepts.html">Concepts</a></li>
 <li class="toctree-l1"><a class="reference internal" href="../../../tutorials/tutorials.html">Tutorials</a></li>
 <li class="toctree-l1 current"><a class="reference internal" href="../../os_user_guide.html">OS User Guide</a><ul class="current">
-<li class="toctree-l2"><a class="reference internal" href="../mynewt_os.html">OS Core</a></li>
-<li class="toctree-l2 current"><a class="reference internal" href="port_os.html">Porting Mynewt OS</a><ul class="current">
+<li class="toctree-l2"><a class="reference internal" href="../mynewt_os.html">Kernel</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../../modules/hal/hal.html">Hardware Abstraction</a></li>
+<li class="toctree-l2 current"><a class="reference internal" href="port_os.html">Porting Guide</a><ul class="current">
 <li class="toctree-l3"><a class="reference internal" href="port_bsp.html">BSP Porting</a></li>
 <li class="toctree-l3 current"><a class="current reference internal" href="#">Porting Mynewt to a new MCU</a></li>
 <li class="toctree-l3"><a class="reference internal" href="port_cpu.html">Porting Mynewt to a new CPU Architecture</a></li>
 </ul>
 </li>
+<li class="toctree-l2"><a class="reference internal" href="../../modules/sysinitconfig/sysinitconfig.html">System Configuration</a></li>
 <li class="toctree-l2"><a class="reference internal" href="../../modules/console/console.html">Console</a></li>
-<li class="toctree-l2"><a class="reference internal" href="../../modules/sysinitconfig/sysinitconfig.html">System Configuration and Initialization</a></li>
 </ul>
 </li>
 <li class="toctree-l1"><a class="reference internal" href="../../../network/ble/ble_intro.html">BLE User Guide</a></li>
diff --git a/develop/os/core_os/porting/port_os.html b/develop/os/core_os/porting/port_os.html
index e755244d0..720ae78fd 100644
--- a/develop/os/core_os/porting/port_os.html
+++ b/develop/os/core_os/porting/port_os.html
@@ -43,7 +43,7 @@
       <link rel="top" title="Apache Mynewt 1.3.0 documentation" href="../../../index.html"/>
           <link rel="up" title="OS User Guide" href="../../os_user_guide.html"/>
           <link rel="next" title="BSP Porting" href="port_bsp.html"/>
-          <link rel="prev" title="Core OS API" href="../API.html"/> 
+          <link rel="prev" title="BSP" href="../../modules/hal/hal_bsp/hal_bsp.html"/> 
 
     
     <script src="../../../_static/js/modernizr.min.js"></script>
@@ -222,15 +222,16 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
 <li class="toctree-l1"><a class="reference internal" href="../../../concepts.html">Concepts</a></li>
 <li class="toctree-l1"><a class="reference internal" href="../../../tutorials/tutorials.html">Tutorials</a></li>
 <li class="toctree-l1 current"><a class="reference internal" href="../../os_user_guide.html">OS User Guide</a><ul class="current">
-<li class="toctree-l2"><a class="reference internal" href="../mynewt_os.html">OS Core</a></li>
-<li class="toctree-l2 current"><a class="current reference internal" href="#">Porting Mynewt OS</a><ul>
+<li class="toctree-l2"><a class="reference internal" href="../mynewt_os.html">Kernel</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../../modules/hal/hal.html">Hardware Abstraction</a></li>
+<li class="toctree-l2 current"><a class="current reference internal" href="#">Porting Guide</a><ul>
 <li class="toctree-l3"><a class="reference internal" href="port_bsp.html">BSP Porting</a></li>
 <li class="toctree-l3"><a class="reference internal" href="port_mcu.html">Porting Mynewt to a new MCU</a></li>
 <li class="toctree-l3"><a class="reference internal" href="port_cpu.html">Porting Mynewt to a new CPU Architecture</a></li>
 </ul>
 </li>
+<li class="toctree-l2"><a class="reference internal" href="../../modules/sysinitconfig/sysinitconfig.html">System Configuration</a></li>
 <li class="toctree-l2"><a class="reference internal" href="../../modules/console/console.html">Console</a></li>
-<li class="toctree-l2"><a class="reference internal" href="../../modules/sysinitconfig/sysinitconfig.html">System Configuration and Initialization</a></li>
 </ul>
 </li>
 <li class="toctree-l1"><a class="reference internal" href="../../../network/ble/ble_intro.html">BLE User Guide</a></li>
@@ -386,7 +387,7 @@ <h2><a class="toc-backref" href="#id5">CPU Core Dependency</a><a class="headerli
         <a href="port_bsp.html" class="btn btn-neutral float-right" title="BSP Porting" accesskey="n">Next: BSP Porting <span class="fa fa-arrow-circle-right"></span></a>
       
       
-        <a href="../API.html" class="btn btn-neutral" title="Core OS API" accesskey="p"><span class="fa fa-arrow-circle-left"></span> Previous: Core OS API</a>
+        <a href="../../modules/hal/hal_bsp/hal_bsp.html" class="btn btn-neutral" title="BSP" accesskey="p"><span class="fa fa-arrow-circle-left"></span> Previous: BSP</a>
       
     </div>
 
diff --git a/develop/os/core_os/sanity/sanity.html b/develop/os/core_os/sanity/sanity.html
index 79c9ca839..38315d4e7 100644
--- a/develop/os/core_os/sanity/sanity.html
+++ b/develop/os/core_os/sanity/sanity.html
@@ -41,9 +41,9 @@
                 href="../../../genindex.html"/>
           <link rel="search" title="Search" href="../../../search.html"/>
       <link rel="top" title="Apache Mynewt 1.3.0 documentation" href="../../../index.html"/>
-          <link rel="up" title="Mynewt Core OS" href="../mynewt_os.html"/>
-          <link rel="next" title="Callout" href="../callout/callout.html"/>
-          <link rel="prev" title="Mqueue" href="../mqueue/mqueue.html"/> 
+          <link rel="up" title="Apache Mynewt Operating System Kernel" href="../mynewt_os.html"/>
+          <link rel="next" title="Hardware Abstraction Layer" href="../../modules/hal/hal.html"/>
+          <link rel="prev" title="OS Time" href="../time/os_time.html"/> 
 
     
     <script src="../../../_static/js/modernizr.min.js"></script>
@@ -156,7 +156,7 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
     
       <a href="../../os_user_guide.html">OS User Guide</a> /
     
-      <a href="../mynewt_os.html">Mynewt Core OS</a> /
+      <a href="../mynewt_os.html">Apache Mynewt Operating System Kernel</a> /
     
     Sanity
     
@@ -224,27 +224,25 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
 <li class="toctree-l1"><a class="reference internal" href="../../../concepts.html">Concepts</a></li>
 <li class="toctree-l1"><a class="reference internal" href="../../../tutorials/tutorials.html">Tutorials</a></li>
 <li class="toctree-l1 current"><a class="reference internal" href="../../os_user_guide.html">OS User Guide</a><ul class="current">
-<li class="toctree-l2 current"><a class="reference internal" href="../mynewt_os.html">OS Core</a><ul class="current">
+<li class="toctree-l2 current"><a class="reference internal" href="../mynewt_os.html">Kernel</a><ul class="current">
 <li class="toctree-l3"><a class="reference internal" href="../context_switch/context_switch.html">Scheduler</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../cputime/os_cputime.html">CPU Time</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../time/os_time.html">OS Time</a></li>
 <li class="toctree-l3"><a class="reference internal" href="../task/task.html">Task</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../event_queue/event_queue.html">Event Queues</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../semaphore/semaphore.html">Semaphore</a></li>
 <li class="toctree-l3"><a class="reference internal" href="../mutex/mutex.html">Mutex</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../memory_pool/memory_pool.html">Memory Pools</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../semaphore/semaphore.html">Semaphore</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../event_queue/event_queue.html">Event Queues</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../callout/callout.html">Callout</a></li>
 <li class="toctree-l3"><a class="reference internal" href="../heap/heap.html">Heap</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../memory_pool/memory_pool.html">Memory Pools</a></li>
 <li class="toctree-l3"><a class="reference internal" href="../mbuf/mbuf.html">Mbufs</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../msys/msys.html">Msys</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../mqueue/mqueue.html">Mqueue</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../cputime/os_cputime.html">CPU Time</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../time/os_time.html">OS Time</a></li>
 <li class="toctree-l3 current"><a class="current reference internal" href="#">Sanity</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../callout/callout.html">Callout</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../API.html">API</a></li>
 </ul>
 </li>
-<li class="toctree-l2"><a class="reference internal" href="../porting/port_os.html">Porting Mynewt OS</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../../modules/hal/hal.html">Hardware Abstraction</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../porting/port_os.html">Porting Guide</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../../modules/sysinitconfig/sysinitconfig.html">System Configuration</a></li>
 <li class="toctree-l2"><a class="reference internal" href="../../modules/console/console.html">Console</a></li>
-<li class="toctree-l2"><a class="reference internal" href="../../modules/sysinitconfig/sysinitconfig.html">System Configuration and Initialization</a></li>
 </ul>
 </li>
 <li class="toctree-l1"><a class="reference internal" href="../../../network/ble/ble_intro.html">BLE User Guide</a></li>
@@ -303,25 +301,25 @@ <h2>Description<a class="headerlink" href="#description" title="Permalink to thi
 </div>
 <div class="section" id="sanity-task">
 <h2>Sanity Task<a class="headerlink" href="#sanity-task" title="Permalink to this headline">?</a></h2>
-<p>Mynewt OS uses the OS Idle task to check sanity. The <code class="docutils literal notranslate"><span class="pre">SANITY_INTERVAL</span></code>
+<p>Mynewt OS uses the OS Idle task to check sanity. The <code class="xref c c-macro docutils literal notranslate"><span class="pre">SANITY_INTERVAL</span></code>
 syscfg setting specifies the interval in seconds to perform the sanity
 checks.</p>
 <p>By default, every operating system task provides the frequency it will
 check in with the sanity task, with the <code class="docutils literal notranslate"><span class="pre">sanity_itvl</span></code> parameter in the
-<code class="docutils literal notranslate"><span class="pre">os_task_init()</span></code> function:</p>
+c:func:<cite>os_task_init()</cite> function:</p>
 <div class="code c highlight-none notranslate"><div class="highlight"><pre><span></span>int os_task_init(struct os_task *t, char *name, os_task_func_t func,
     void *arg, uint8_t prio, os_time_t sanity_itvl, os_stack_t *bottom,
     uint16_t stack_size);
 </pre></div>
 </div>
-<p><code class="docutils literal notranslate"><span class="pre">sanity_itvl</span></code> is the time in OS time ticks that the task being created
+<p>c:var:<cite>sanity_itvl</cite> is the time in OS time ticks that the task being created
 must register in with the sanity task.</p>
 </div>
 <div class="section" id="checking-in-with-sanity-task">
 <h2>Checking in with Sanity Task<a class="headerlink" href="#checking-in-with-sanity-task" title="Permalink to this headline">?</a></h2>
 <p>The task must then register in with the sanity task every
 <code class="docutils literal notranslate"><span class="pre">sanity_itvl</span></code> seconds. In order to do that, the task should call the
-<code class="docutils literal notranslate"><span class="pre">os_sanity_task_checkin</span></code> function, which will reset the sanity check
+<a class="reference internal" href="#c.os_sanity_task_checkin" title="os_sanity_task_checkin"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_sanity_task_checkin()</span></code></a> function, which will reset the sanity check
 associated with this task. Here is an example of a task that uses a
 callout to checkin with the sanity task every 50 seconds:</p>
 <div class="code c highlight-none notranslate"><div class="highlight"><pre><span></span>#define TASK1_SANITY_CHECKIN_ITVL (50 * OS_TICKS_PER_SEC)
@@ -370,8 +368,8 @@ <h2>Checking in with Sanity Task<a class="headerlink" href="#checking-in-with-sa
 <h2>Registering a Custom Sanity Check<a class="headerlink" href="#registering-a-custom-sanity-check" title="Permalink to this headline">?</a></h2>
 <p>If a particular task wants to further hook into the sanity framework to
 perform other checks during the sanity task?s operation, it can do so by
-registering a <code class="docutils literal notranslate"><span class="pre">struct</span> <span class="pre">os_sanity_check</span></code> using the
-<code class="docutils literal notranslate"><span class="pre">os_sanity_check_register</span></code> function.</p>
+registering a <code class="xref c c-type docutils literal notranslate"><span class="pre">struct</span> <span class="pre">os_sanity_check</span></code> using the
+<a class="reference internal" href="#c.os_sanity_check_register" title="os_sanity_check_register"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_sanity_check_register()</span></code></a> function.</p>
 <div class="code c highlight-none notranslate"><div class="highlight"><pre><span></span>static int
 mymodule_perform_sanity_check(struct os_sanity_check *sc, void *arg)
 {
@@ -412,8 +410,8 @@ <h2>Registering a Custom Sanity Check<a class="headerlink" href="#registering-a-
 </div>
 <p>In the above example, every time the custom sanity check
 <code class="docutils literal notranslate"><span class="pre">mymodule_perform_sanity_check</span></code> returns successfully (0), the sanity
-check is reset. In the <code class="docutils literal notranslate"><span class="pre">OS_SANITY_CHECK_SETFUNC</span></code> macro, the sanity
-checkin interval is specified as 50 * SANITY_TASK_INTERVAL (which is
+check is reset. In the c:macro:<cite>OS_SANITY_CHECK_SETFUNC</cite> macro, the sanity
+checkin interval is specified as 50 * <code class="xref c c-macro docutils literal notranslate"><span class="pre">SANITY_TASK_INTERVAL</span></code> (which is
 the interval at which the sanity task runs.) This means that the
 <code class="docutils literal notranslate"><span class="pre">mymodule_perform_sanity_check()</span></code> function needs to fail 50 times
 consecutively before the sanity task will crash the system.</p>
@@ -422,92 +420,114 @@ <h2>Registering a Custom Sanity Check<a class="headerlink" href="#registering-a-
 multiple consecutive times before crashing the system. This will avoid
 crashing for temporary failures.</p>
 </div>
-<div class="section" id="data-structures">
-<h2>Data structures<a class="headerlink" href="#data-structures" title="Permalink to this headline">?</a></h2>
-</div>
-<div class="section" id="os-sanity-check">
-<h2>OS Sanity Check<a class="headerlink" href="#os-sanity-check" title="Permalink to this headline">?</a></h2>
-<div class="code c highlight-none notranslate"><div class="highlight"><pre><span></span>struct os_sanity_check {
-    os_time_t sc_checkin_last;
-    os_time_t sc_checkin_itvl;
-    os_sanity_check_func_t sc_func;
-    void *sc_arg;
-
-    SLIST_ENTRY(os_sanity_check) sc_next;
-};
-</pre></div>
-</div>
-<table border="1" class="docutils">
-<colgroup>
-<col width="47%" />
-<col width="53%" />
-</colgroup>
-<thead valign="bottom">
-<tr class="row-odd"><th class="head"><strong>Element</strong></th>
-<th class="head"><a href="#id1"><span class="problematic" id="id2">**</span></a>Description*
-*</th>
-</tr>
-</thead>
-<tbody valign="top">
-<tr class="row-even"><td><code class="docutils literal notranslate"><span class="pre">sc_checkin</span>
-<span class="pre">_last</span></code></td>
-<td>The last time
-this sanity
-check checked
-in with the
-sanity task,
-in OS time
-ticks.</td>
-</tr>
-<tr class="row-odd"><td><code class="docutils literal notranslate"><span class="pre">sc_checkin</span>
-<span class="pre">_itvl</span></code></td>
-<td>How frequently
-the sanity
-check is
-supposed to
-check in with
-the sanity
-task, in OS
-time ticks.</td>
-</tr>
-<tr class="row-even"><td><code class="docutils literal notranslate"><span class="pre">sc_func</span></code></td>
-<td>If not
-<code class="docutils literal notranslate"><span class="pre">NULL</span></code>, call
-this function
-when running
-the sanity
-task. If the
-function
-returns 0,
-reset the
-sanity check.</td>
-</tr>
-<tr class="row-odd"><td><code class="docutils literal notranslate"><span class="pre">sc_arg</span></code></td>
-<td>Argument to
-pass to
-<code class="docutils literal notranslate"><span class="pre">sc_func</span></code>
-when calling
-it.</td>
-</tr>
-<tr class="row-even"><td><code class="docutils literal notranslate"><span class="pre">sc_next</span></code></td>
-<td>Sanity checks
-are chained in
-the sanity
-task when
-<a href="#id3"><span class="problematic" id="id4">``</span></a>os_sanity_ch
-eck_register()
-``
-is called.</td>
-</tr>
-</tbody>
-</table>
-</div>
 <div class="section" id="api">
 <h2>API<a class="headerlink" href="#api" title="Permalink to this headline">?</a></h2>
-<div class="admonition warning">
-<p class="first admonition-title">Warning</p>
-<p class="last">doxygengroup: Cannot find namespace ?OSSanity? in doxygen xml output for project ?mynewt-core? from directory: mynewt-core-xml</p>
+<dl class="typedef">
+<dt id="c.os_sanity_check_func_t">
+<span class="target" id="group___o_s_sanity_1ga354458457ad42d0bab3d8d08de482fc9"></span><em class="property">typedef </em>int<code class="descname">(* os_sanity_check_func_t)</code><span class="sig-paren">(</span>struct os_sanity_check<em>&nbsp;*</em>, void<em>&nbsp;*</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_sanity_check_func_t" title="Permalink to this definition">?</a></dt>
+<dd></dd></dl>
+
+<dl class="function">
+<dt id="c.os_sanity_task_checkin">
+<span class="target" id="group___o_s_sanity_1ga048cde3537cb470594fc2528201572ba"></span>int <code class="descname">os_sanity_task_checkin</code><span class="sig-paren">(</span>struct  os_task <em>&nbsp;*</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_sanity_task_checkin" title="Permalink to this definition">?</a></dt>
+<dd><p>Provide a ?task checkin? for the sanity task. </p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>0 on success, error code on failure </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">t</span></code>: The task to check in</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_sanity_check_init">
+<span class="target" id="group___o_s_sanity_1ga34eb185813afec28e2d61059e2fdd064"></span>int <code class="descname">os_sanity_check_init</code><span class="sig-paren">(</span>struct  os_sanity_check <em>&nbsp;*</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_sanity_check_init" title="Permalink to this definition">?</a></dt>
+<dd><p>Initialize a sanity check. </p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>0 on success, error code on failure. </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">sc</span></code>: The sanity check to initialize</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_sanity_check_register">
+<span class="target" id="group___o_s_sanity_1ga2c5ad3969bf12870a0adfa7b9a8a8611"></span>int <code class="descname">os_sanity_check_register</code><span class="sig-paren">(</span>struct  os_sanity_check <em>&nbsp;*</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_sanity_check_register" title="Permalink to this definition">?</a></dt>
+<dd><p>Register a sanity check. </p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>0 on success, error code on failure </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">sc</span></code>: The sanity check to register</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_sanity_check_reset">
+<span class="target" id="group___o_s_sanity_1ga92ea98a26001d84aee06d600c62b7140"></span>int <code class="descname">os_sanity_check_reset</code><span class="sig-paren">(</span>struct  os_sanity_check <em>&nbsp;*</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_sanity_check_reset" title="Permalink to this definition">?</a></dt>
+<dd><p>Reset the os sanity check, so that it doesn?t trip up the sanity timer. </p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>0 on success, error code on failure </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">sc</span></code>: The sanity check to reset</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="define">
+<dt id="c.OS_SANITY_CHECK_SETFUNC">
+<span class="target" id="group___o_s_sanity_1ga53501a44869b9cda63c92f031d8a46c5"></span><code class="descname">OS_SANITY_CHECK_SETFUNC</code><span class="sig-paren">(</span>__sc, __f, __arg, __itvl<span class="sig-paren">)</span><a class="headerlink" href="#c.OS_SANITY_CHECK_SETFUNC" title="Permalink to this definition">?</a></dt>
+<dd></dd></dl>
+
+<dl class="class">
+<dt id="_CPPv315os_sanity_check">
+<span id="_CPPv215os_sanity_check"></span><span id="os_sanity_check"></span><span class="target" id="structos__sanity__check"></span><em class="property">struct </em><code class="descname">os_sanity_check</code><a class="headerlink" href="#_CPPv315os_sanity_check" title="Permalink to this definition">?</a><br /></dt>
+<dd><em>#include &lt;os_sanity.h&gt;</em><div class="breathe-sectiondef docutils container">
+<p class="breathe-sectiondef-title rubric">Public Members</p>
+<dl class="variable">
+<dt id="c.os_sanity_check::sc_checkin_last">
+<span class="target" id="structos__sanity__check_1a7701ac67d9e7ba081cef9a6540a35003"></span><a class="reference internal" href="../time/os_time.html#c.os_time_t" title="os_time_t">os_time_t</a> <code class="descname">sc_checkin_last</code><a class="headerlink" href="#c.os_sanity_check::sc_checkin_last" title="Permalink to this definition">?</a></dt>
+<dd><p>Time this check last ran successfully. </p>
+</dd></dl>
+
+<dl class="variable">
+<dt id="c.os_sanity_check::sc_checkin_itvl">
+<span class="target" id="structos__sanity__check_1ad9b79d0e7c0dcc9fcbfe57d2b7d43c53"></span><a class="reference internal" href="../time/os_time.html#c.os_time_t" title="os_time_t">os_time_t</a> <code class="descname">sc_checkin_itvl</code><a class="headerlink" href="#c.os_sanity_check::sc_checkin_itvl" title="Permalink to this definition">?</a></dt>
+<dd><p>Interval this task should check in at. </p>
+</dd></dl>
+
+<dl class="variable">
+<dt id="c.os_sanity_check::sc_func">
+<span class="target" id="structos__sanity__check_1ab5be2cbf4891bc9f42f25b7f4cfb9b45"></span><a class="reference internal" href="#c.os_sanity_check_func_t" title="os_sanity_check_func_t">os_sanity_check_func_t</a> <code class="descname">sc_func</code><a class="headerlink" href="#c.os_sanity_check::sc_func" title="Permalink to this definition">?</a></dt>
+<dd><p>Sanity check to run. </p>
+</dd></dl>
+
+<dl class="variable">
+<dt id="c.os_sanity_check::sc_arg">
+<span class="target" id="structos__sanity__check_1a5b22c20409427a0561fb2418a251706a"></span>void* <code class="descname">sc_arg</code><a class="headerlink" href="#c.os_sanity_check::sc_arg" title="Permalink to this definition">?</a></dt>
+<dd><p>Argument to pass to sanity check. </p>
+</dd></dl>
+
 </div>
+</dd></dl>
+
 </div>
 </div>
 
@@ -517,10 +537,10 @@ <h2>API<a class="headerlink" href="#api" title="Permalink to this headline">?</
                   
     <div class="rst-footer-buttons row" role="navigation" aria-label="footer navigation">
       
-        <a href="../callout/callout.html" class="btn btn-neutral float-right" title="Callout" accesskey="n">Next: Callout <span class="fa fa-arrow-circle-right"></span></a>
+        <a href="../../modules/hal/hal.html" class="btn btn-neutral float-right" title="Hardware Abstraction Layer" accesskey="n">Next: Hardware Abstraction Layer <span class="fa fa-arrow-circle-right"></span></a>
       
       
-        <a href="../mqueue/mqueue.html" class="btn btn-neutral" title="Mqueue" accesskey="p"><span class="fa fa-arrow-circle-left"></span> Previous: Mqueue</a>
+        <a href="../time/os_time.html" class="btn btn-neutral" title="OS Time" accesskey="p"><span class="fa fa-arrow-circle-left"></span> Previous: OS Time</a>
       
     </div>
 
diff --git a/develop/os/core_os/semaphore/semaphore.html b/develop/os/core_os/semaphore/semaphore.html
index 35606e7ac..398450172 100644
--- a/develop/os/core_os/semaphore/semaphore.html
+++ b/develop/os/core_os/semaphore/semaphore.html
@@ -41,9 +41,9 @@
                 href="../../../genindex.html"/>
           <link rel="search" title="Search" href="../../../search.html"/>
       <link rel="top" title="Apache Mynewt 1.3.0 documentation" href="../../../index.html"/>
-          <link rel="up" title="Mynewt Core OS" href="../mynewt_os.html"/>
-          <link rel="next" title="Mutex" href="../mutex/mutex.html"/>
-          <link rel="prev" title="Event Queues" href="../event_queue/event_queue.html"/> 
+          <link rel="up" title="Apache Mynewt Operating System Kernel" href="../mynewt_os.html"/>
+          <link rel="next" title="Event Queues" href="../event_queue/event_queue.html"/>
+          <link rel="prev" title="Mutex" href="../mutex/mutex.html"/> 
 
     
     <script src="../../../_static/js/modernizr.min.js"></script>
@@ -156,7 +156,7 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
     
       <a href="../../os_user_guide.html">OS User Guide</a> /
     
-      <a href="../mynewt_os.html">Mynewt Core OS</a> /
+      <a href="../mynewt_os.html">Apache Mynewt Operating System Kernel</a> /
     
     Semaphore
     
@@ -224,27 +224,25 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
 <li class="toctree-l1"><a class="reference internal" href="../../../concepts.html">Concepts</a></li>
 <li class="toctree-l1"><a class="reference internal" href="../../../tutorials/tutorials.html">Tutorials</a></li>
 <li class="toctree-l1 current"><a class="reference internal" href="../../os_user_guide.html">OS User Guide</a><ul class="current">
-<li class="toctree-l2 current"><a class="reference internal" href="../mynewt_os.html">OS Core</a><ul class="current">
+<li class="toctree-l2 current"><a class="reference internal" href="../mynewt_os.html">Kernel</a><ul class="current">
 <li class="toctree-l3"><a class="reference internal" href="../context_switch/context_switch.html">Scheduler</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../cputime/os_cputime.html">CPU Time</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../time/os_time.html">OS Time</a></li>
 <li class="toctree-l3"><a class="reference internal" href="../task/task.html">Task</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../event_queue/event_queue.html">Event Queues</a></li>
-<li class="toctree-l3 current"><a class="current reference internal" href="#">Semaphore</a></li>
 <li class="toctree-l3"><a class="reference internal" href="../mutex/mutex.html">Mutex</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../memory_pool/memory_pool.html">Memory Pools</a></li>
+<li class="toctree-l3 current"><a class="current reference internal" href="#">Semaphore</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../event_queue/event_queue.html">Event Queues</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../callout/callout.html">Callout</a></li>
 <li class="toctree-l3"><a class="reference internal" href="../heap/heap.html">Heap</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../memory_pool/memory_pool.html">Memory Pools</a></li>
 <li class="toctree-l3"><a class="reference internal" href="../mbuf/mbuf.html">Mbufs</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../msys/msys.html">Msys</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../mqueue/mqueue.html">Mqueue</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../cputime/os_cputime.html">CPU Time</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../time/os_time.html">OS Time</a></li>
 <li class="toctree-l3"><a class="reference internal" href="../sanity/sanity.html">Sanity</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../callout/callout.html">Callout</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../API.html">API</a></li>
 </ul>
 </li>
-<li class="toctree-l2"><a class="reference internal" href="../porting/port_os.html">Porting Mynewt OS</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../../modules/hal/hal.html">Hardware Abstraction</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../porting/port_os.html">Porting Guide</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../../modules/sysinitconfig/sysinitconfig.html">System Configuration</a></li>
 <li class="toctree-l2"><a class="reference internal" href="../../modules/console/console.html">Console</a></li>
-<li class="toctree-l2"><a class="reference internal" href="../../modules/sysinitconfig/sysinitconfig.html">System Configuration and Initialization</a></li>
 </ul>
 </li>
 <li class="toctree-l1"><a class="reference internal" href="../../../network/ble/ble_intro.html">BLE User Guide</a></li>
@@ -295,9 +293,9 @@ <h2>Description<a class="headerlink" href="#description" title="Permalink to thi
 semaphore, the initial number of tokens can be set as well.</p>
 <p>When used for exclusive access to a shared resource the semaphore only
 needs a single token. In this case, a single task ?creates? the
-semaphore by calling <em>os_sem_init</em> with a value of one (1) for the
+semaphore by calling <a class="reference internal" href="#c.os_sem_init" title="os_sem_init"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_sem_init()</span></code></a> with a value of one (1) for the
 token. When a task desires exclusive access to the shared resource it
-requests the semaphore by calling <em>os_sem_pend</em>. If there is a token
+requests the semaphore by calling <a class="reference internal" href="#c.os_sem_pend" title="os_sem_pend"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_sem_pend()</span></code></a>. If there is a token
 the requesting task will acquire the semaphore and continue operation.
 If no tokens are available the task will be put to sleep until there is
 a token. A common ?problem? with using a semaphore for exclusive access
@@ -320,60 +318,94 @@ <h2>Description<a class="headerlink" href="#description" title="Permalink to thi
 initializes it with no tokens. The task then waits on the semaphore, and
 since there are no tokens, the task is put to sleep. When other tasks
 want to wake up the sleeping task they simply add a token by calling
-<em>os_sem_release</em>. This will cause the sleeping task to wake up
+<a class="reference internal" href="#c.os_sem_release" title="os_sem_release"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_sem_release()</span></code></a>. This will cause the sleeping task to wake up
 (instantly if no other higher priority tasks want to run).</p>
 <p>The other common use of a counting semaphore is in what is commonly
 called a ?producer/consumer? relationship. The producer adds tokens (by
-calling <em>os_sem_release</em>) and the consumer consumes them by calling
-<em>os_sem_pend</em>. In this relationship, the producer has work for the
+calling <a class="reference internal" href="#c.os_sem_release" title="os_sem_release"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_sem_release()</span></code></a>) and the consumer consumes them by calling
+<a class="reference internal" href="#c.os_sem_pend" title="os_sem_pend"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_sem_pend()</span></code></a>. In this relationship, the producer has work for the
 consumer to do. Each token added to the semaphore will cause the
 consumer to do whatever work is required. A simple example could be the
 following: every time a button is pressed there is some work to do (ring
 a bell). Each button press causes the producer to add a token. Each
 token consumed rings the bell. There will exactly the same number of
 bell rings as there are button presses. In other words, each call to
-<em>os_sem_pend</em> subtracts exactly one token and each call to
-<em>os_sem_release</em> adds exactly one token.</p>
-</div>
-<div class="section" id="data-structures">
-<h2>Data structures<a class="headerlink" href="#data-structures" title="Permalink to this headline">?</a></h2>
-<div class="code c highlight-none notranslate"><div class="highlight"><pre><span></span>struct os_sem
-{
-    SLIST_HEAD(, os_task) sem_head;     /* chain of waiting tasks */
-    uint16_t    _pad;
-    uint16_t    sem_tokens;             /* # of tokens */
-};
-</pre></div>
-</div>
-<table border="1" class="docutils">
-<colgroup>
-<col width="22%" />
-<col width="78%" />
-</colgroup>
-<thead valign="bottom">
-<tr class="row-odd"><th class="head">Element</th>
-<th class="head">Description</th>
-</tr>
-</thead>
-<tbody valign="top">
-<tr class="row-even"><td>sem_head</td>
-<td>Queue head for list of tasks waiting on semaphore</td>
-</tr>
-<tr class="row-odd"><td>_pad</td>
-<td>Padding for alignment</td>
-</tr>
-<tr class="row-even"><td>sem_tokens</td>
-<td>Current number of tokens</td>
-</tr>
-</tbody>
-</table>
+<a class="reference internal" href="#c.os_sem_pend" title="os_sem_pend"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_sem_pend()</span></code></a> subtracts exactly one token and each call to
+<a class="reference internal" href="#c.os_sem_release" title="os_sem_release"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_sem_release()</span></code></a> adds exactly one token.</p>
 </div>
 <div class="section" id="api">
 <h2>API<a class="headerlink" href="#api" title="Permalink to this headline">?</a></h2>
-<div class="admonition warning">
-<p class="first admonition-title">Warning</p>
-<p class="last">doxygengroup: Cannot find namespace ?OSSem? in doxygen xml output for project ?mynewt-core? from directory: mynewt-core-xml</p>
+<dl class="function">
+<dt id="c.os_sem_init">
+<span class="target" id="group___o_s_sem_1ga8f44f453e0bb9447272d67bce13c9f34"></span>os_error_t <code class="descname">os_sem_init</code><span class="sig-paren">(</span>struct  os_sem  *<em>&nbsp;sem</em>, uint16_t<em>&nbsp;tokens</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_sem_init" title="Permalink to this definition">?</a></dt>
+<dd><p>Initialize a semaphore. </p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>os_error_t OS_INVALID_PARM Semaphore passed in was NULL. OS_OK no error. </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">sem</span></code>: Pointer to semaphore tokens: # of tokens the semaphore should contain initially.</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_sem_release">
+<span class="target" id="group___o_s_sem_1ga909a7fa9280e8871cba64e3dce5d6768"></span>os_error_t <code class="descname">os_sem_release</code><span class="sig-paren">(</span>struct  os_sem  *<em>&nbsp;sem</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_sem_release" title="Permalink to this definition">?</a></dt>
+<dd><p>Release a semaphore. </p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>os_error_t OS_INVALID_PARM Semaphore passed in was NULL. OS_OK No error </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">sem</span></code>: Pointer to the semaphore to be released</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_sem_pend">
+<span class="target" id="group___o_s_sem_1ga2d7ed24cd6d1b1326bd7d57784202955"></span>os_error_t <code class="descname">os_sem_pend</code><span class="sig-paren">(</span>struct  os_sem  *<em>&nbsp;sem</em>, uint32_t<em>&nbsp;timeout</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_sem_pend" title="Permalink to this definition">?</a></dt>
+<dd><p>os sem pend </p>
+<p>Pend (wait) for a semaphore.</p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>os_error_t OS_INVALID_PARM Semaphore passed in was NULL. OS_TIMEOUT Semaphore was owned by another task and timeout=0 OS_OK no error. </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">mu</span></code>: Pointer to semaphore. </li>
+<li><code class="docutils literal notranslate"><span class="pre">timeout</span></code>: Timeout, in os ticks. A timeout of 0 means do not wait if not available. A timeout of 0xFFFFFFFF means wait forever.</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_sem_get_count">
+<span class="target" id="group___o_s_sem_1gac83a58d5a5a64e0c1bfbadc2a0611539"></span>static uint16_t <code class="descname">os_sem_get_count</code><span class="sig-paren">(</span>struct  os_sem  *<em>&nbsp;sem</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_sem_get_count" title="Permalink to this definition">?</a></dt>
+<dd><p>Get current semaphore?s count. </p>
+</dd></dl>
+
+<dl class="class">
+<dt id="_CPPv36os_sem">
+<span id="_CPPv26os_sem"></span><span id="os_sem"></span><span class="target" id="structos__sem"></span><em class="property">struct </em><code class="descname">os_sem</code><a class="headerlink" href="#_CPPv36os_sem" title="Permalink to this definition">?</a><br /></dt>
+<dd><em>#include &lt;os_sem.h&gt;</em><p>Structure representing an OS semaphore. </p>
+<div class="breathe-sectiondef docutils container">
+<p class="breathe-sectiondef-title rubric">Public Members</p>
+<dl class="variable">
+<dt id="c.os_sem::sem_tokens">
+<span class="target" id="structos__sem_1a2bd4c88720d5a9581fe7959c2a5db686"></span>uint16_t <code class="descname">sem_tokens</code><a class="headerlink" href="#c.os_sem::sem_tokens" title="Permalink to this definition">?</a></dt>
+<dd><p>Number of tokens. </p>
+</dd></dl>
+
 </div>
+</dd></dl>
+
 </div>
 </div>
 
@@ -383,10 +415,10 @@ <h2>API<a class="headerlink" href="#api" title="Permalink to this headline">?</
                   
     <div class="rst-footer-buttons row" role="navigation" aria-label="footer navigation">
       
-        <a href="../mutex/mutex.html" class="btn btn-neutral float-right" title="Mutex" accesskey="n">Next: Mutex <span class="fa fa-arrow-circle-right"></span></a>
+        <a href="../event_queue/event_queue.html" class="btn btn-neutral float-right" title="Event Queues" accesskey="n">Next: Event Queues <span class="fa fa-arrow-circle-right"></span></a>
       
       
-        <a href="../event_queue/event_queue.html" class="btn btn-neutral" title="Event Queues" accesskey="p"><span class="fa fa-arrow-circle-left"></span> Previous: Event Queues</a>
+        <a href="../mutex/mutex.html" class="btn btn-neutral" title="Mutex" accesskey="p"><span class="fa fa-arrow-circle-left"></span> Previous: Mutex</a>
       
     </div>
 
diff --git a/develop/os/core_os/task/task.html b/develop/os/core_os/task/task.html
index 14fd0feda..bee45526a 100644
--- a/develop/os/core_os/task/task.html
+++ b/develop/os/core_os/task/task.html
@@ -41,9 +41,9 @@
                 href="../../../genindex.html"/>
           <link rel="search" title="Search" href="../../../search.html"/>
       <link rel="top" title="Apache Mynewt 1.3.0 documentation" href="../../../index.html"/>
-          <link rel="up" title="Mynewt Core OS" href="../mynewt_os.html"/>
-          <link rel="next" title="Event Queues" href="../event_queue/event_queue.html"/>
-          <link rel="prev" title="OS Time" href="../time/os_time.html"/> 
+          <link rel="up" title="Apache Mynewt Operating System Kernel" href="../mynewt_os.html"/>
+          <link rel="next" title="Mutex" href="../mutex/mutex.html"/>
+          <link rel="prev" title="Scheduler" href="../context_switch/context_switch.html"/> 
 
     
     <script src="../../../_static/js/modernizr.min.js"></script>
@@ -156,7 +156,7 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
     
       <a href="../../os_user_guide.html">OS User Guide</a> /
     
-      <a href="../mynewt_os.html">Mynewt Core OS</a> /
+      <a href="../mynewt_os.html">Apache Mynewt Operating System Kernel</a> /
     
     Task
     
@@ -224,27 +224,25 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
 <li class="toctree-l1"><a class="reference internal" href="../../../concepts.html">Concepts</a></li>
 <li class="toctree-l1"><a class="reference internal" href="../../../tutorials/tutorials.html">Tutorials</a></li>
 <li class="toctree-l1 current"><a class="reference internal" href="../../os_user_guide.html">OS User Guide</a><ul class="current">
-<li class="toctree-l2 current"><a class="reference internal" href="../mynewt_os.html">OS Core</a><ul class="current">
+<li class="toctree-l2 current"><a class="reference internal" href="../mynewt_os.html">Kernel</a><ul class="current">
 <li class="toctree-l3"><a class="reference internal" href="../context_switch/context_switch.html">Scheduler</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../cputime/os_cputime.html">CPU Time</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../time/os_time.html">OS Time</a></li>
 <li class="toctree-l3 current"><a class="current reference internal" href="#">Task</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../event_queue/event_queue.html">Event Queues</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../semaphore/semaphore.html">Semaphore</a></li>
 <li class="toctree-l3"><a class="reference internal" href="../mutex/mutex.html">Mutex</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../memory_pool/memory_pool.html">Memory Pools</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../semaphore/semaphore.html">Semaphore</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../event_queue/event_queue.html">Event Queues</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../callout/callout.html">Callout</a></li>
 <li class="toctree-l3"><a class="reference internal" href="../heap/heap.html">Heap</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../memory_pool/memory_pool.html">Memory Pools</a></li>
 <li class="toctree-l3"><a class="reference internal" href="../mbuf/mbuf.html">Mbufs</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../msys/msys.html">Msys</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../mqueue/mqueue.html">Mqueue</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../cputime/os_cputime.html">CPU Time</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../time/os_time.html">OS Time</a></li>
 <li class="toctree-l3"><a class="reference internal" href="../sanity/sanity.html">Sanity</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../callout/callout.html">Callout</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../API.html">API</a></li>
 </ul>
 </li>
-<li class="toctree-l2"><a class="reference internal" href="../porting/port_os.html">Porting Mynewt OS</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../../modules/hal/hal.html">Hardware Abstraction</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../porting/port_os.html">Porting Guide</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../../modules/sysinitconfig/sysinitconfig.html">System Configuration</a></li>
 <li class="toctree-l2"><a class="reference internal" href="../../modules/console/console.html">Console</a></li>
-<li class="toctree-l2"><a class="reference internal" href="../../modules/sysinitconfig/sysinitconfig.html">System Configuration and Initialization</a></li>
 </ul>
 </li>
 <li class="toctree-l1"><a class="reference internal" href="../../../network/ble/ble_intro.html">BLE User Guide</a></li>
@@ -298,7 +296,7 @@ <h1>Task<a class="headerlink" href="#task" title="Permalink to this headline">?
 lower priority tasks will never get a chance to run (actually, any task
 lower in priority than the task that never sleeps). A task will be put
 to sleep in the following cases: it puts itself to sleep using
-<a class="reference internal" href="../API.html#c.os_time_delay" title="os_time_delay"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_time_delay()</span></code></a>, it waits on an event queue which is empty or
+<a class="reference internal" href="../time/os_time.html#c.os_time_delay" title="os_time_delay"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_time_delay()</span></code></a>, it waits on an event queue which is empty or
 attempts to obtain a mutex or a semaphore that is currently owned by
 another task.</p>
 <p>Note that other sections of the manual describe these OS features in
@@ -311,7 +309,7 @@ <h2>Description<a class="headerlink" href="#description" title="Permalink to thi
 large local variables on the stack so that task stacks can be of limited
 size. However, all applications are different and the developer must
 choose the stack size accordingly. NOTE: be careful when declaring your
-stack! The stack is in units of <code class="docutils literal notranslate"><span class="pre">os_stack_t</span></code> sized elements (generally
+stack! The stack is in units of <code class="xref c c-type docutils literal notranslate"><span class="pre">os_stack_t</span></code> sized elements (generally
 32-bits). Looking at the example given below and assuming <code class="docutils literal notranslate"><span class="pre">os_stack_t</span></code>
 is defined to be a 32-bit unsigned value, ?my_task_stack? will use 256
 bytes.</p>
@@ -319,19 +317,19 @@ <h2>Description<a class="headerlink" href="#description" title="Permalink to thi
 function that will be called when the task is first run. This task
 function should never return!</p>
 <p>In order to inform the Mynewt OS of the new task and to have it added to
-the scheduler, the <a class="reference internal" href="../API.html#c.os_task_init" title="os_task_init"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_task_init()</span></code></a> function is called. Once
-<a class="reference internal" href="../API.html#c.os_task_init" title="os_task_init"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_task_init()</span></code></a> is called, the task is made ready to run and is added
+the scheduler, the <a class="reference internal" href="#c.os_task_init" title="os_task_init"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_task_init()</span></code></a> function is called. Once
+<a class="reference internal" href="#c.os_task_init" title="os_task_init"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_task_init()</span></code></a> is called, the task is made ready to run and is added
 to the active task list. Note that a task can be initialized (started)
-before or after the os has started (i.e. before <a class="reference internal" href="../API.html#c.os_start" title="os_start"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_start()</span></code></a> is
+before or after the os has started (i.e. before <code class="xref c c-func docutils literal notranslate"><span class="pre">os_start()</span></code> is
 called) but must be initialized after the os has been initialized (i.e.
-<a class="reference internal" href="../API.html#c.os_init" title="os_init"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_init()</span></code></a> has been called). In most of the examples and current Mynewt
+<code class="xref c c-func docutils literal notranslate"><span class="pre">os_init()</span></code> has been called). In most of the examples and current Mynewt
 projects, the os is initialized, tasks are initialized, and the the os
 is started. Once the os has started, the highest priority task will be
 the first task set to run.</p>
 <p>Information about a task can be obtained using the
-<a class="reference internal" href="../API.html#c.os_task_info_get_next" title="os_task_info_get_next"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_task_info_get_next()</span></code></a> API. Developers can walk the list of tasks
+<a class="reference internal" href="#c.os_task_info_get_next" title="os_task_info_get_next"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_task_info_get_next()</span></code></a> API. Developers can walk the list of tasks
 to obtain information on all created tasks. This information is of type
-<a class="reference internal" href="../API.html#c.os_task_info" title="os_task_info"><code class="xref c c-data docutils literal notranslate"><span class="pre">os_task_info</span></code></a>.</p>
+<code class="xref c c-data docutils literal notranslate"><span class="pre">os_task_info</span></code>.</p>
 <p>The following is a very simple example showing a single application
 task. This task simply toggles an LED at a one second interval.</p>
 <div class="highlight-c notranslate"><div class="highlight"><pre><span></span><span class="cm">/* Create a simple &quot;project&quot; with a task that blinks a LED every second */</span>
@@ -376,6 +374,313 @@ <h2>Description<a class="headerlink" href="#description" title="Permalink to thi
 <span class="p">}</span>
 </pre></div>
 </div>
+</div>
+<div class="section" id="api">
+<h2>API<a class="headerlink" href="#api" title="Permalink to this headline">?</a></h2>
+<dl class="enum">
+<dt id="c.OSTask::os_task_state">
+<span class="target" id="group___o_s_task_1ga897c47c6381207ebaea3963c43362f88"></span><em class="property">enum </em><code class="descclassname">OSTask::</code><code class="descname">os_task_state</code><a class="headerlink" href="#c.OSTask::os_task_state" title="Permalink to this definition">?</a></dt>
+<dd><p>Task states. </p>
+<p><em>Values:</em></p>
+<dl class="enumvalue">
+<dt id="c.OSTask::OS_TASK_READY">
+<span class="target" id="group___o_s_task_1gga897c47c6381207ebaea3963c43362f88a529cd0e1f131f501efe7cc3d1122d002"></span><code class="descname">OS_TASK_READY</code> = 1<a class="headerlink" href="#c.OSTask::OS_TASK_READY" title="Permalink to this definition">?</a></dt>
+<dd><p>Task is ready to run. </p>
+</dd></dl>
+
+<dl class="enumvalue">
+<dt id="c.OSTask::OS_TASK_SLEEP">
+<span class="target" id="group___o_s_task_1gga897c47c6381207ebaea3963c43362f88af7cdfa32e836ac0ef16f761a00dd6104"></span><code class="descname">OS_TASK_SLEEP</code> = 2<a class="headerlink" href="#c.OSTask::OS_TASK_SLEEP" title="Permalink to this definition">?</a></dt>
+<dd><p>Task is sleeping. </p>
+</dd></dl>
+
+</dd></dl>
+
+<dl class="typedef">
+<dt id="c.os_task_state_t">
+<span class="target" id="group___o_s_task_1ga106cd7d63dabd9800363a0c9b5ff40d1"></span><em class="property">typedef </em>enum os_task_state  <code class="descname">os_task_state_t</code><a class="headerlink" href="#c.os_task_state_t" title="Permalink to this definition">?</a></dt>
+<dd><p>Task states. </p>
+</dd></dl>
+
+<dl class="typedef">
+<dt id="c.os_task_func_t">
+<span class="target" id="group___o_s_task_1ga831f9a3ebc7c5e7b4aac94d581eba82c"></span><em class="property">typedef </em>void<code class="descname">(* os_task_func_t)</code><span class="sig-paren">(</span>void<em>&nbsp;*</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_task_func_t" title="Permalink to this definition">?</a></dt>
+<dd></dd></dl>
+
+<dl class="function">
+<dt id="c.os_task_init">
+<span class="target" id="group___o_s_task_1gac0604d800ed8dbfd18835cd5076a6393"></span>int <code class="descname">os_task_init</code><span class="sig-paren">(</span>struct  os_task <em>&nbsp;*</em>, const char<em>&nbsp;*</em>, <a class="reference internal" href="#c.os_task_func_t" title="os_task_func_t">os_task_func_t</a>, void<em>&nbsp;*</em>, uint8_t, <a class="reference internal" href="../time/os_time.html#c.os_time_t" title="os_time_t">os_time_t</a>, os_stack_t <em>&nbsp;*</em>, uint16_t<span class="sig-paren">)</span><a class="headerlink" href="#c.os_task_init" title="Permalink to this definition">?</a></dt>
+<dd><p>Initialize a task. </p>
+<p>This function initializes the task structure pointed to by t, clearing and setting it?s stack pointer, provides sane defaults and sets the task as ready to run, and inserts it into the operating system scheduler.</p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>0 on success, non-zero on failure. </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">t</span></code>: The task to initialize </li>
+<li><code class="docutils literal notranslate"><span class="pre">name</span></code>: The name of the task to initialize </li>
+<li><code class="docutils literal notranslate"><span class="pre">func</span></code>: The task function to call </li>
+<li><code class="docutils literal notranslate"><span class="pre">arg</span></code>: The argument to pass to this task function </li>
+<li><code class="docutils literal notranslate"><span class="pre">prio</span></code>: The priority at which to run this task </li>
+<li><code class="docutils literal notranslate"><span class="pre">sanity_itvl</span></code>: The time at which this task should check in with the sanity task. OS_WAIT_FOREVER means never check in here. </li>
+<li><code class="docutils literal notranslate"><span class="pre">stack_bottom</span></code>: A pointer to the bottom of a task?s stack </li>
+<li><code class="docutils literal notranslate"><span class="pre">stack_size</span></code>: The overall size of the task?s stack.</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_task_remove">
+<span class="target" id="group___o_s_task_1gacf6cfe441ddecead6a2e010165384cb4"></span>int <code class="descname">os_task_remove</code><span class="sig-paren">(</span>struct  os_task  *<em>&nbsp;t</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_task_remove" title="Permalink to this definition">?</a></dt>
+<dd><p>Removes specified task XXX NOTE: This interface is currently experimental and not ready for common use. </p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_task_count">
+<span class="target" id="group___o_s_task_1ga6b14a4fbff91ab3e9fd4b9933423a590"></span>uint8_t <code class="descname">os_task_count</code><span class="sig-paren">(</span>void<span class="sig-paren">)</span><a class="headerlink" href="#c.os_task_count" title="Permalink to this definition">?</a></dt>
+<dd><p>Return the number of tasks initialized. </p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>number of tasks initialized </dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_task_info_get_next">
+<span class="target" id="group___o_s_task_1gac459b82ad909a99ff1ef0ec3cedc31d2"></span>struct os_task* <code class="descname">os_task_info_get_next</code><span class="sig-paren">(</span>const struct  os_task <em>&nbsp;*</em>, struct  os_task_info <em>&nbsp;*</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_task_info_get_next" title="Permalink to this definition">?</a></dt>
+<dd><p>Iterate through tasks, and return the following information about them: </p>
+<p><ul class="simple">
+<li>Priority</li>
+<li>Task ID</li>
+<li>State (READY, SLEEP)</li>
+<li>Total Stack Usage</li>
+<li>Stack Size</li>
+<li>Context Switch Count</li>
+<li>Runtime</li>
+<li>Last &amp; Next Sanity checkin</li>
+<li>Task Name</li>
+</ul>
+</p>
+<p>To get the first task in the list, call <a class="reference internal" href="#group___o_s_task_1gac459b82ad909a99ff1ef0ec3cedc31d2"><span class="std std-ref">os_task_info_get_next()</span></a> with a NULL pointer in the prev argument, and <a class="reference internal" href="#group___o_s_task_1gac459b82ad909a99ff1ef0ec3cedc31d2"><span class="std std-ref">os_task_info_get_next()</span></a> will return a pointer to the task structure, and fill out the <a class="reference internal" href="#structos__task__info"><span class="std std-ref">os_task_info</span></a> structure pointed to by oti.</p>
+<p>To get the next task in the list, provide the task structure returned by the previous call to <a class="reference internal" href="#group___o_s_task_1gac459b82ad909a99ff1ef0ec3cedc31d2"><span class="std std-ref">os_task_info_get_next()</span></a>, and <a class="reference internal" href="#group___o_s_task_1gac459b82ad909a99ff1ef0ec3cedc31d2"><span class="std std-ref">os_task_info_get_next()</span></a> will fill out the task structure pointed to by oti again, and return the next task in the list.</p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>A pointer to the OS task that has been read, or NULL when finished iterating through all tasks. </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">prev</span></code>: The previous task returned by <a class="reference internal" href="#group___o_s_task_1gac459b82ad909a99ff1ef0ec3cedc31d2"><span class="std std-ref">os_task_info_get_next()</span></a>, or NULL to begin iteration. </li>
+<li><code class="docutils literal notranslate"><span class="pre">oti</span></code>: The OS task info structure to fill out.</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="define">
+<dt id="c.OS_TASK_PRI_HIGHEST">
+<span class="target" id="group___o_s_task_1ga93bc03e4d136b0262c3be351546d90a3"></span><code class="descname">OS_TASK_PRI_HIGHEST</code><a class="headerlink" href="#c.OS_TASK_PRI_HIGHEST" title="Permalink to this definition">?</a></dt>
+<dd><p>Highest priority task. </p>
+</dd></dl>
+
+<dl class="define">
+<dt id="c.OS_TASK_PRI_LOWEST">
+<span class="target" id="group___o_s_task_1ga3b2c641ef3afd2033ab312b900634cca"></span><code class="descname">OS_TASK_PRI_LOWEST</code><a class="headerlink" href="#c.OS_TASK_PRI_LOWEST" title="Permalink to this definition">?</a></dt>
+<dd><p>Lowest priority task. </p>
+</dd></dl>
+
+<dl class="define">
+<dt id="c.OS_TASK_FLAG_NO_TIMEOUT">
+<span class="target" id="group___o_s_task_1ga0728b4db08cbfa190ffe8748fe3430bc"></span><code class="descname">OS_TASK_FLAG_NO_TIMEOUT</code><a class="headerlink" href="#c.OS_TASK_FLAG_NO_TIMEOUT" title="Permalink to this definition">?</a></dt>
+<dd></dd></dl>
+
+<dl class="define">
+<dt id="c.OS_TASK_FLAG_SEM_WAIT">
+<span class="target" id="group___o_s_task_1ga86f7848c389417413b98191082717d08"></span><code class="descname">OS_TASK_FLAG_SEM_WAIT</code><a class="headerlink" href="#c.OS_TASK_FLAG_SEM_WAIT" title="Permalink to this definition">?</a></dt>
+<dd><p>Task waiting on a semaphore. </p>
+</dd></dl>
+
+<dl class="define">
+<dt id="c.OS_TASK_FLAG_MUTEX_WAIT">
+<span class="target" id="group___o_s_task_1gaab125531a2394b65d7327c5f09cff689"></span><code class="descname">OS_TASK_FLAG_MUTEX_WAIT</code><a class="headerlink" href="#c.OS_TASK_FLAG_MUTEX_WAIT" title="Permalink to this definition">?</a></dt>
+<dd><p>Task waiting on a mutex. </p>
+</dd></dl>
+
+<dl class="define">
+<dt id="c.OS_TASK_FLAG_EVQ_WAIT">
+<span class="target" id="group___o_s_task_1ga7886a157f2de8c02484404050fc1c7ac"></span><code class="descname">OS_TASK_FLAG_EVQ_WAIT</code><a class="headerlink" href="#c.OS_TASK_FLAG_EVQ_WAIT" title="Permalink to this definition">?</a></dt>
+<dd><p>Task waiting on a event queue. </p>
+</dd></dl>
+
+<dl class="define">
+<dt id="c.OS_TASK_MAX_NAME_LEN">
+<span class="target" id="group___o_s_task_1gab9a4544def04dd6cfbaf93cd51785452"></span><code class="descname">OS_TASK_MAX_NAME_LEN</code><a class="headerlink" href="#c.OS_TASK_MAX_NAME_LEN" title="Permalink to this definition">?</a></dt>
+<dd></dd></dl>
+
+<dl class="class">
+<dt id="_CPPv37os_task">
+<span id="_CPPv27os_task"></span><span id="os_task"></span><span class="target" id="structos__task"></span><em class="property">struct </em><code class="descname">os_task</code><a class="headerlink" href="#_CPPv37os_task" title="Permalink to this definition">?</a><br /></dt>
+<dd><em>#include &lt;os_task.h&gt;</em><p>Structure containing information about a running task. </p>
+<div class="breathe-sectiondef docutils container">
+<p class="breathe-sectiondef-title rubric">Public Members</p>
+<dl class="variable">
+<dt id="c.os_task::t_stackptr">
+<span class="target" id="structos__task_1afe949cfd7c42a5cb31bf8755b26ce01e"></span>os_stack_t* <code class="descname">t_stackptr</code><a class="headerlink" href="#c.os_task::t_stackptr" title="Permalink to this definition">?</a></dt>
+<dd><p>Current stack pointer for this task. </p>
+</dd></dl>
+
+<dl class="variable">
+<dt id="c.os_task::t_stacktop">
+<span class="target" id="structos__task_1a40c3ba56a847758812bc417949724588"></span>os_stack_t* <code class="descname">t_stacktop</code><a class="headerlink" href="#c.os_task::t_stacktop" title="Permalink to this definition">?</a></dt>
+<dd><p>Pointer to top of this task?s stack. </p>
+</dd></dl>
+
+<dl class="variable">
+<dt id="c.os_task::t_stacksize">
+<span class="target" id="structos__task_1a732f272fc82004d997f87a9a906729d0"></span>uint16_t <code class="descname">t_stacksize</code><a class="headerlink" href="#c.os_task::t_stacksize" title="Permalink to this definition">?</a></dt>
+<dd><p>Size of this task?s stack. </p>
+</dd></dl>
+
+<dl class="variable">
+<dt id="c.os_task::t_taskid">
+<span class="target" id="structos__task_1a9fbae9501044635c01be92ac56d01b4c"></span>uint8_t <code class="descname">t_taskid</code><a class="headerlink" href="#c.os_task::t_taskid" title="Permalink to this definition">?</a></dt>
+<dd><p>Task ID. </p>
+</dd></dl>
+
+<dl class="variable">
+<dt id="c.os_task::t_prio">
+<span class="target" id="structos__task_1a412fe15c516151b1864e3e77b4d79199"></span>uint8_t <code class="descname">t_prio</code><a class="headerlink" href="#c.os_task::t_prio" title="Permalink to this definition">?</a></dt>
+<dd><p>Task Priority. </p>
+</dd></dl>
+
+<dl class="variable">
+<dt id="c.os_task::t_flags">
+<span class="target" id="structos__task_1af58aa554823b3ae3655b6672d2bf93ca"></span>uint8_t <code class="descname">t_flags</code><a class="headerlink" href="#c.os_task::t_flags" title="Permalink to this definition">?</a></dt>
+<dd><p>Task flags, bitmask. </p>
+</dd></dl>
+
+<dl class="variable">
+<dt id="c.os_task::t_name">
+<span class="target" id="structos__task_1a617c03d12fe7051db4c6b032f4c764a8"></span>const char* <code class="descname">t_name</code><a class="headerlink" href="#c.os_task::t_name" title="Permalink to this definition">?</a></dt>
+<dd><p>Task name. </p>
+</dd></dl>
+
+<dl class="variable">
+<dt id="c.os_task::t_func">
+<span class="target" id="structos__task_1a2a2d6ea1f625cd6a90c6e6f6a5aba160"></span><a class="reference internal" href="#c.os_task_func_t" title="os_task_func_t">os_task_func_t</a> <code class="descname">t_func</code><a class="headerlink" href="#c.os_task::t_func" title="Permalink to this definition">?</a></dt>
+<dd><p>Task function that executes. </p>
+</dd></dl>
+
+<dl class="variable">
+<dt id="c.os_task::t_arg">
+<span class="target" id="structos__task_1a39b3109b30ba2c821cad2cca3dd77fec"></span>void* <code class="descname">t_arg</code><a class="headerlink" href="#c.os_task::t_arg" title="Permalink to this definition">?</a></dt>
+<dd><p>Argument to pass to task function when called. </p>
+</dd></dl>
+
+<dl class="variable">
+<dt id="c.os_task::t_obj">
+<span class="target" id="structos__task_1aa23d60f19ae3e48f859b40cafd83f1ae"></span>void* <code class="descname">t_obj</code><a class="headerlink" href="#c.os_task::t_obj" title="Permalink to this definition">?</a></dt>
+<dd><p>Current object task is waiting on, either a semaphore or mutex. </p>
+</dd></dl>
+
+<dl class="variable">
+<dt id="c.os_task::t_sanity_check">
+<span class="target" id="structos__task_1a24958d799042b17927b0f94405f193cf"></span>struct os_sanity_check <code class="descname">t_sanity_check</code><a class="headerlink" href="#c.os_task::t_sanity_check" title="Permalink to this definition">?</a></dt>
+<dd><p>Default sanity check for this task. </p>
+</dd></dl>
+
+<dl class="variable">
+<dt id="c.os_task::t_next_wakeup">
+<span class="target" id="structos__task_1adc9eebeea4dd7cb212de3ee04b113a71"></span><a class="reference internal" href="../time/os_time.html#c.os_time_t" title="os_time_t">os_time_t</a> <code class="descname">t_next_wakeup</code><a class="headerlink" href="#c.os_task::t_next_wakeup" title="Permalink to this definition">?</a></dt>
+<dd><p>Next scheduled wakeup if this task is sleeping. </p>
+</dd></dl>
+
+<dl class="variable">
+<dt id="c.os_task::t_run_time">
+<span class="target" id="structos__task_1a980815aadda46b23373395854907ef0b"></span><a class="reference internal" href="../time/os_time.html#c.os_time_t" title="os_time_t">os_time_t</a> <code class="descname">t_run_time</code><a class="headerlink" href="#c.os_task::t_run_time" title="Permalink to this definition">?</a></dt>
+<dd><p>Total task run time. </p>
+</dd></dl>
+
+<dl class="variable">
+<dt id="c.os_task::t_ctx_sw_cnt">
+<span class="target" id="structos__task_1a0c51f9ebf2d06ec8e3f5bddd860606e1"></span>uint32_t <code class="descname">t_ctx_sw_cnt</code><a class="headerlink" href="#c.os_task::t_ctx_sw_cnt" title="Permalink to this definition">?</a></dt>
+<dd><p>Total number of times this task has been context switched during execution. </p>
+</dd></dl>
+
+</div>
+</dd></dl>
+
+<dl class="class">
+<dt id="_CPPv312os_task_info">
+<span id="_CPPv212os_task_info"></span><span id="os_task_info"></span><span class="target" id="structos__task__info"></span><em class="property">struct </em><code class="descname">os_task_info</code><a class="headerlink" href="#_CPPv312os_task_info" title="Permalink to this definition">?</a><br /></dt>
+<dd><em>#include &lt;os_task.h&gt;</em><p>Information about an individual task, returned for management APIs. </p>
+<div class="breathe-sectiondef docutils container">
+<p class="breathe-sectiondef-title rubric">Public Members</p>
+<dl class="variable">
+<dt id="c.os_task_info::oti_prio">
+<span class="target" id="structos__task__info_1a3b9e108c245f706c1f238639e1fcc411"></span>uint8_t <code class="descname">oti_prio</code><a class="headerlink" href="#c.os_task_info::oti_prio" title="Permalink to this definition">?</a></dt>
+<dd><p>Task priority. </p>
+</dd></dl>
+
+<dl class="variable">
+<dt id="c.os_task_info::oti_taskid">
+<span class="target" id="structos__task__info_1acfc3100a590d117396ba39bdc14c9fe1"></span>uint8_t <code class="descname">oti_taskid</code><a class="headerlink" href="#c.os_task_info::oti_taskid" title="Permalink to this definition">?</a></dt>
+<dd><p>Task identifier. </p>
+</dd></dl>
+
+<dl class="variable">
+<dt id="c.os_task_info::oti_state">
+<span class="target" id="structos__task__info_1a887a2fae644c0d174423ce1724f91a0e"></span>uint8_t <code class="descname">oti_state</code><a class="headerlink" href="#c.os_task_info::oti_state" title="Permalink to this definition">?</a></dt>
+<dd><p>Task state, either READY or SLEEP. </p>
+</dd></dl>
+
+<dl class="variable">
+<dt id="c.os_task_info::oti_stkusage">
+<span class="target" id="structos__task__info_1af660e42807b73fac357753873f89baf0"></span>uint16_t <code class="descname">oti_stkusage</code><a class="headerlink" href="#c.os_task_info::oti_stkusage" title="Permalink to this definition">?</a></dt>
+<dd><p>Task stack usage. </p>
+</dd></dl>
+
+<dl class="variable">
+<dt id="c.os_task_info::oti_stksize">
+<span class="target" id="structos__task__info_1ac306d37cb458c796e7bd876ce3724acc"></span>uint16_t <code class="descname">oti_stksize</code><a class="headerlink" href="#c.os_task_info::oti_stksize" title="Permalink to this definition">?</a></dt>
+<dd><p>Task stack size. </p>
+</dd></dl>
+
+<dl class="variable">
+<dt id="c.os_task_info::oti_cswcnt">
+<span class="target" id="structos__task__info_1a9acbf3e6b3a274ab40951ef54c75ab38"></span>uint32_t <code class="descname">oti_cswcnt</code><a class="headerlink" href="#c.os_task_info::oti_cswcnt" title="Permalink to this definition">?</a></dt>
+<dd><p>Task context switch count. </p>
+</dd></dl>
+
+<dl class="variable">
+<dt id="c.os_task_info::oti_runtime">
+<span class="target" id="structos__task__info_1aeefcf9aeb3aaad24f401d56089842dd8"></span>uint32_t <code class="descname">oti_runtime</code><a class="headerlink" href="#c.os_task_info::oti_runtime" title="Permalink to this definition">?</a></dt>
+<dd><p>Task runtime. </p>
+</dd></dl>
+
+<dl class="variable">
+<dt id="c.os_task_info::oti_last_checkin">
+<span class="target" id="structos__task__info_1a7b5a7274c1237db848cdc04e97f6a715"></span><a class="reference internal" href="../time/os_time.html#c.os_time_t" title="os_time_t">os_time_t</a> <code class="descname">oti_last_checkin</code><a class="headerlink" href="#c.os_task_info::oti_last_checkin" title="Permalink to this definition">?</a></dt>
+<dd><p>Last time this task checked in with sanity. </p>
+</dd></dl>
+
+<dl class="variable">
+<dt id="c.os_task_info::oti_next_checkin">
+<span class="target" id="structos__task__info_1a5f851a446f55aa79f258cab528d10dfe"></span><a class="reference internal" href="../time/os_time.html#c.os_time_t" title="os_time_t">os_time_t</a> <code class="descname">oti_next_checkin</code><a class="headerlink" href="#c.os_task_info::oti_next_checkin" title="Permalink to this definition">?</a></dt>
+<dd><p>Next time this task is scheduled to check-in with sanity. </p>
+</dd></dl>
+
+<dl class="variable">
+<dt>
+<span class="target" id="structos__task__info_1a100f609783651bcbd369982613570f72"></span><code class="descname">char os_task_info::oti_name[OS_TASK_MAX_NAME_LEN]</code></dt>
+<dd><p>Name of this task. </p>
+</dd></dl>
+
+</div>
+</dd></dl>
+
 </div>
 </div>
 
@@ -385,10 +690,10 @@ <h2>Description<a class="headerlink" href="#description" title="Permalink to thi
                   
     <div class="rst-footer-buttons row" role="navigation" aria-label="footer navigation">
       
-        <a href="../event_queue/event_queue.html" class="btn btn-neutral float-right" title="Event Queues" accesskey="n">Next: Event Queues <span class="fa fa-arrow-circle-right"></span></a>
+        <a href="../mutex/mutex.html" class="btn btn-neutral float-right" title="Mutex" accesskey="n">Next: Mutex <span class="fa fa-arrow-circle-right"></span></a>
       
       
-        <a href="../time/os_time.html" class="btn btn-neutral" title="OS Time" accesskey="p"><span class="fa fa-arrow-circle-left"></span> Previous: OS Time</a>
+        <a href="../context_switch/context_switch.html" class="btn btn-neutral" title="Scheduler" accesskey="p"><span class="fa fa-arrow-circle-left"></span> Previous: Scheduler</a>
       
     </div>
 
diff --git a/develop/os/core_os/time/os_time.html b/develop/os/core_os/time/os_time.html
index 6d774faf3..64b7bf728 100644
--- a/develop/os/core_os/time/os_time.html
+++ b/develop/os/core_os/time/os_time.html
@@ -41,8 +41,8 @@
                 href="../../../genindex.html"/>
           <link rel="search" title="Search" href="../../../search.html"/>
       <link rel="top" title="Apache Mynewt 1.3.0 documentation" href="../../../index.html"/>
-          <link rel="up" title="Mynewt Core OS" href="../mynewt_os.html"/>
-          <link rel="next" title="Task" href="../task/task.html"/>
+          <link rel="up" title="Apache Mynewt Operating System Kernel" href="../mynewt_os.html"/>
+          <link rel="next" title="Sanity" href="../sanity/sanity.html"/>
           <link rel="prev" title="CPU Time" href="../cputime/os_cputime.html"/> 
 
     
@@ -156,7 +156,7 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
     
       <a href="../../os_user_guide.html">OS User Guide</a> /
     
-      <a href="../mynewt_os.html">Mynewt Core OS</a> /
+      <a href="../mynewt_os.html">Apache Mynewt Operating System Kernel</a> /
     
     OS Time
     
@@ -224,27 +224,25 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
 <li class="toctree-l1"><a class="reference internal" href="../../../concepts.html">Concepts</a></li>
 <li class="toctree-l1"><a class="reference internal" href="../../../tutorials/tutorials.html">Tutorials</a></li>
 <li class="toctree-l1 current"><a class="reference internal" href="../../os_user_guide.html">OS User Guide</a><ul class="current">
-<li class="toctree-l2 current"><a class="reference internal" href="../mynewt_os.html">OS Core</a><ul class="current">
+<li class="toctree-l2 current"><a class="reference internal" href="../mynewt_os.html">Kernel</a><ul class="current">
 <li class="toctree-l3"><a class="reference internal" href="../context_switch/context_switch.html">Scheduler</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../cputime/os_cputime.html">CPU Time</a></li>
-<li class="toctree-l3 current"><a class="current reference internal" href="#">OS Time</a></li>
 <li class="toctree-l3"><a class="reference internal" href="../task/task.html">Task</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../event_queue/event_queue.html">Event Queues</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../semaphore/semaphore.html">Semaphore</a></li>
 <li class="toctree-l3"><a class="reference internal" href="../mutex/mutex.html">Mutex</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../memory_pool/memory_pool.html">Memory Pools</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../semaphore/semaphore.html">Semaphore</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../event_queue/event_queue.html">Event Queues</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../callout/callout.html">Callout</a></li>
 <li class="toctree-l3"><a class="reference internal" href="../heap/heap.html">Heap</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../memory_pool/memory_pool.html">Memory Pools</a></li>
 <li class="toctree-l3"><a class="reference internal" href="../mbuf/mbuf.html">Mbufs</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../msys/msys.html">Msys</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../mqueue/mqueue.html">Mqueue</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../cputime/os_cputime.html">CPU Time</a></li>
+<li class="toctree-l3 current"><a class="current reference internal" href="#">OS Time</a></li>
 <li class="toctree-l3"><a class="reference internal" href="../sanity/sanity.html">Sanity</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../callout/callout.html">Callout</a></li>
-<li class="toctree-l3"><a class="reference internal" href="../API.html">API</a></li>
 </ul>
 </li>
-<li class="toctree-l2"><a class="reference internal" href="../porting/port_os.html">Porting Mynewt OS</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../../modules/hal/hal.html">Hardware Abstraction</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../porting/port_os.html">Porting Guide</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../../modules/sysinitconfig/sysinitconfig.html">System Configuration</a></li>
 <li class="toctree-l2"><a class="reference internal" href="../../modules/console/console.html">Console</a></li>
-<li class="toctree-l2"><a class="reference internal" href="../../modules/sysinitconfig/sysinitconfig.html">System Configuration and Initialization</a></li>
 </ul>
 </li>
 <li class="toctree-l1"><a class="reference internal" href="../../../network/ble/ble_intro.html">BLE User Guide</a></li>
@@ -288,6 +286,7 @@ <h1>OS Time<a class="headerlink" href="#os-time" title="Permalink to this headli
 <li><a class="reference internal" href="#functions" id="id3">Functions</a></li>
 <li><a class="reference internal" href="#macros" id="id4">Macros</a></li>
 <li><a class="reference internal" href="#special-notes" id="id5">Special Notes</a></li>
+<li><a class="reference internal" href="#api" id="id6">API</a></li>
 </ul>
 </div>
 <div class="section" id="description">
@@ -305,10 +304,10 @@ <h2><a class="toc-backref" href="#id1">Description</a><a class="headerlink" href
 </div>
 <div class="section" id="data-structures">
 <h2><a class="toc-backref" href="#id2">Data Structures</a><a class="headerlink" href="#data-structures" title="Permalink to this headline">?</a></h2>
-<p>Time is stored in Mynewt as an <a class="reference internal" href="../API.html#c.os_time_t" title="os_time_t"><code class="xref c c-type docutils literal notranslate"><span class="pre">os_time_t</span></code></a> value.</p>
-<p>Wallclock time is represented using the <a class="reference internal" href="../API.html#c.os_timeval" title="os_timeval"><code class="xref c c-data docutils literal notranslate"><span class="pre">struct</span> <span class="pre">os_timeval</span></code></a> and
-<a class="reference internal" href="../API.html#c.os_timezone" title="os_timezone"><code class="xref c c-data docutils literal notranslate"><span class="pre">struct</span> <span class="pre">os_timezone</span></code></a> tuple.</p>
-<p><a class="reference internal" href="../API.html#c.os_timeval" title="os_timeval"><code class="xref c c-data docutils literal notranslate"><span class="pre">struct</span> <span class="pre">os_timeval</span></code></a> represents the number of seconds elapsed since
+<p>Time is stored in Mynewt as an <a class="reference internal" href="#c.os_time_t" title="os_time_t"><code class="xref c c-type docutils literal notranslate"><span class="pre">os_time_t</span></code></a> value.</p>
+<p>Wallclock time is represented using the <code class="xref c c-data docutils literal notranslate"><span class="pre">struct</span> <span class="pre">os_timeval</span></code> and
+<code class="xref c c-data docutils literal notranslate"><span class="pre">struct</span> <span class="pre">os_timezone</span></code> tuple.</p>
+<p><code class="xref c c-data docutils literal notranslate"><span class="pre">struct</span> <span class="pre">os_timeval</span></code> represents the number of seconds elapsed since
 00:00:00 Jan 1, 1970 UTC.</p>
 <div class="highlight-c notranslate"><div class="highlight"><pre><span></span><span class="k">struct</span> <span class="n">os_timeval</span> <span class="p">{</span>
     <span class="kt">int64_t</span> <span class="n">tv_sec</span><span class="p">;</span>  <span class="cm">/* seconds since Jan 1 1970 UTC */</span>
@@ -318,7 +317,7 @@ <h2><a class="toc-backref" href="#id2">Data Structures</a><a class="headerlink"
 <span class="k">struct</span> <span class="n">os_timeval</span> <span class="n">tv</span> <span class="o">=</span> <span class="p">{</span> <span class="mi">1457400000</span><span class="p">,</span> <span class="mi">0</span> <span class="p">};</span>  <span class="cm">/* 01:20:00 Mar 8 2016 UTC */</span>
 </pre></div>
 </div>
-<p><a class="reference internal" href="../API.html#c.os_timezone" title="os_timezone"><code class="xref c c-data docutils literal notranslate"><span class="pre">struct</span> <span class="pre">os_timezone</span></code></a> is used to specify the offset of local time from
+<p><code class="xref c c-data docutils literal notranslate"><span class="pre">struct</span> <span class="pre">os_timezone</span></code> is used to specify the offset of local time from
 UTC and whether daylight savings is in effect. Note that <code class="docutils literal notranslate"><span class="pre">tz_minuteswest</span></code> is a positive number
 if the local time is <em>behind</em> UTC and a negative number if the local time is <em>ahead</em> of UTC.</p>
 <div class="highlight-c notranslate"><div class="highlight"><pre><span></span><span class="k">struct</span> <span class="n">os_timezone</span> <span class="p">{</span>
@@ -348,25 +347,25 @@ <h2><a class="toc-backref" href="#id3">Functions</a><a class="headerlink" href="
 </tr>
 </thead>
 <tbody valign="top">
-<tr class="row-even"><td><a class="reference internal" href="../API.html#c.os_time_advance" title="os_time_advance"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_time_advance()</span></code></a></td>
+<tr class="row-even"><td><a class="reference internal" href="#c.os_time_advance" title="os_time_advance"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_time_advance()</span></code></a></td>
 <td>Increments the OS time tick for the system.</td>
 </tr>
-<tr class="row-odd"><td><a class="reference internal" href="../API.html#c.os_time_delay" title="os_time_delay"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_time_delay()</span></code></a></td>
+<tr class="row-odd"><td><a class="reference internal" href="#c.os_time_delay" title="os_time_delay"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_time_delay()</span></code></a></td>
 <td>Put the current task to sleep for the given number of ticks.</td>
 </tr>
-<tr class="row-even"><td><a class="reference internal" href="../API.html#c.os_time_get" title="os_time_get"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_time_get()</span></code></a></td>
+<tr class="row-even"><td><a class="reference internal" href="#c.os_time_get" title="os_time_get"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_time_get()</span></code></a></td>
 <td>Get the current value of OS time.</td>
 </tr>
-<tr class="row-odd"><td><a class="reference internal" href="../API.html#c.os_time_ms_to_ticks" title="os_time_ms_to_ticks"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_time_ms_to_ticks()</span></code></a></td>
+<tr class="row-odd"><td><a class="reference internal" href="#c.os_time_ms_to_ticks" title="os_time_ms_to_ticks"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_time_ms_to_ticks()</span></code></a></td>
 <td>Converts milliseconds to os ticks.</td>
 </tr>
-<tr class="row-even"><td><a class="reference internal" href="../API.html#c.os_get_uptime_usec" title="os_get_uptime_usec"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_get_uptime_usec()</span></code></a></td>
+<tr class="row-even"><td><a class="reference internal" href="#c.os_get_uptime_usec" title="os_get_uptime_usec"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_get_uptime_usec()</span></code></a></td>
 <td>Gets the time duration since boot.</td>
 </tr>
-<tr class="row-odd"><td><a class="reference internal" href="../API.html#c.os_gettimeofday" title="os_gettimeofday"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_gettimeofday()</span></code></a></td>
+<tr class="row-odd"><td><a class="reference internal" href="#c.os_gettimeofday" title="os_gettimeofday"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_gettimeofday()</span></code></a></td>
 <td>Populate the given timeval and timezone structs with current time data.</td>
 </tr>
-<tr class="row-even"><td><a class="reference internal" href="../API.html#c.os_settimeofday" title="os_settimeofday"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_settimeofday()</span></code></a></td>
+<tr class="row-even"><td><a class="reference internal" href="#c.os_settimeofday" title="os_settimeofday"><code class="xref c c-func docutils literal notranslate"><span class="pre">os_settimeofday()</span></code></a></td>
 <td>Set the current time of day to the given time structs.</td>
 </tr>
 </tbody>
@@ -377,11 +376,11 @@ <h2><a class="toc-backref" href="#id4">Macros</a><a class="headerlink" href="#ma
 <p>Several macros help with the evalution of times with respect to each
 other.</p>
 <ul class="simple">
-<li><a class="reference internal" href="../API.html#c.OS_TIME_TICK_LT" title="OS_TIME_TICK_LT"><code class="xref c c-macro docutils literal notranslate"><span class="pre">OS_TIME_TICK_LT</span></code></a> ? evaluates to true if t1 is before t2 in
+<li><a class="reference internal" href="#c.OS_TIME_TICK_LT" title="OS_TIME_TICK_LT"><code class="xref c c-macro docutils literal notranslate"><span class="pre">OS_TIME_TICK_LT</span></code></a> ? evaluates to true if t1 is before t2 in
 time.</li>
-<li><a class="reference internal" href="../API.html#c.OS_TIME_TICK_GT" title="OS_TIME_TICK_GT"><code class="xref c c-macro docutils literal notranslate"><span class="pre">OS_TIME_TICK_GT</span></code></a> ? evaluates to true if t1 is after t2 in
+<li><a class="reference internal" href="#c.OS_TIME_TICK_GT" title="OS_TIME_TICK_GT"><code class="xref c c-macro docutils literal notranslate"><span class="pre">OS_TIME_TICK_GT</span></code></a> ? evaluates to true if t1 is after t2 in
 time</li>
-<li><a class="reference internal" href="../API.html#c.OS_TIME_TICK_GEQ" title="OS_TIME_TICK_GEQ"><code class="xref c c-macro docutils literal notranslate"><span class="pre">OS_TIME_TICK_GEQ</span></code></a> ? evaluates to true if t1 is on or after
+<li><a class="reference internal" href="#c.OS_TIME_TICK_GEQ" title="OS_TIME_TICK_GEQ"><code class="xref c c-macro docutils literal notranslate"><span class="pre">OS_TIME_TICK_GEQ</span></code></a> ? evaluates to true if t1 is on or after
 t2 in time.</li>
 </ul>
 <p>NOTE: For all of these macros the calculations are done modulo
@@ -389,12 +388,12 @@ <h2><a class="toc-backref" href="#id4">Macros</a><a class="headerlink" href="#ma
 <p>Ensure that comparison of OS time always uses the macros above (to
 compensate for the possible wrap of OS time).</p>
 <p>The following macros help adding or subtracting time when represented as
-<a class="reference internal" href="../API.html#c.os_timeval" title="os_timeval"><code class="xref c c-data docutils literal notranslate"><span class="pre">struct</span> <span class="pre">os_timeval</span></code></a>. All parameters to the following macros are
-pointers to <a class="reference internal" href="../API.html#c.os_timeval" title="os_timeval"><code class="xref c c-data docutils literal notranslate"><span class="pre">struct</span> <span class="pre">os_timeval</span></code></a>.</p>
+<code class="xref c c-data docutils literal notranslate"><span class="pre">struct</span> <span class="pre">os_timeval</span></code>. All parameters to the following macros are
+pointers to <code class="xref c c-data docutils literal notranslate"><span class="pre">struct</span> <span class="pre">os_timeval</span></code>.</p>
 <ul class="simple">
-<li><a class="reference internal" href="../API.html#c.os_timeradd" title="os_timeradd"><code class="xref c c-macro docutils literal notranslate"><span class="pre">os_timeradd</span></code></a> ? Add <code class="docutils literal notranslate"><span class="pre">uvp</span></code> to <code class="docutils literal notranslate"><span class="pre">tvp</span></code> and store
+<li><a class="reference internal" href="#c.os_timeradd" title="os_timeradd"><code class="xref c c-macro docutils literal notranslate"><span class="pre">os_timeradd</span></code></a> ? Add <code class="docutils literal notranslate"><span class="pre">uvp</span></code> to <code class="docutils literal notranslate"><span class="pre">tvp</span></code> and store
 result in <code class="docutils literal notranslate"><span class="pre">vvp</span></code>.</li>
-<li><a class="reference internal" href="../API.html#c.os_timersub" title="os_timersub"><code class="xref c c-macro docutils literal notranslate"><span class="pre">os_timersub</span></code></a> ? Subtract <code class="docutils literal notranslate"><span class="pre">uvp</span></code> from <code class="docutils literal notranslate"><span class="pre">tvp</span></code> and
+<li><a class="reference internal" href="#c.os_timersub" title="os_timersub"><code class="xref c c-macro docutils literal notranslate"><span class="pre">os_timersub</span></code></a> ? Subtract <code class="docutils literal notranslate"><span class="pre">uvp</span></code> from <code class="docutils literal notranslate"><span class="pre">tvp</span></code> and
 store result in <code class="docutils literal notranslate"><span class="pre">vvp</span></code>.</li>
 </ul>
 </div>
@@ -402,12 +401,193 @@ <h2><a class="toc-backref" href="#id4">Macros</a><a class="headerlink" href="#ma
 <h2><a class="toc-backref" href="#id5">Special Notes</a><a class="headerlink" href="#special-notes" title="Permalink to this headline">?</a></h2>
 <p>Its important to understand how quickly the time wraps especially when
 doing time comparison using the macros above (or by any other means).</p>
-<p>For example, if a tick is 1 millisecond and <a class="reference internal" href="../API.html#c.os_time_t" title="os_time_t"><code class="xref c c-type docutils literal notranslate"><span class="pre">os_time_t</span></code></a> is 32-bits the
+<p>For example, if a tick is 1 millisecond and <a class="reference internal" href="#c.os_time_t" title="os_time_t"><code class="xref c c-type docutils literal notranslate"><span class="pre">os_time_t</span></code></a> is 32-bits the
 OS time will wrap back to zero in about 49.7 days or stated another way,
 the OS time epoch is 49.7 days.</p>
 <p>If two times are more than 1/2 the OS time epoch apart, any time
 comparison will be incorrect. Ensure at design time that comparisons
 will not occur between times that are more than half the OS time epoch.</p>
+</div>
+<div class="section" id="api">
+<h2><a class="toc-backref" href="#id6">API</a><a class="headerlink" href="#api" title="Permalink to this headline">?</a></h2>
+<dl class="typedef">
+<dt id="c.os_time_t">
+<span class="target" id="group___o_s_time_1gaa2378cafc0f8fbfb44633036348bfe64"></span><em class="property">typedef </em>uint32_t <code class="descname">os_time_t</code><a class="headerlink" href="#c.os_time_t" title="Permalink to this definition">?</a></dt>
+<dd></dd></dl>
+
+<dl class="typedef">
+<dt id="c.os_stime_t">
+<span class="target" id="group___o_s_time_1ga7557d3ce9091f57daa64e5d3187067f4"></span><em class="property">typedef </em>int32_t <code class="descname">os_stime_t</code><a class="headerlink" href="#c.os_stime_t" title="Permalink to this definition">?</a></dt>
+<dd></dd></dl>
+
+<dl class="function">
+<dt id="c.os_time_get">
+<span class="target" id="group___o_s_time_1gac20647237280640f96f61558fb7f0762"></span><a class="reference internal" href="#c.os_time_t" title="os_time_t">os_time_t</a> <code class="descname">os_time_get</code><span class="sig-paren">(</span>void<span class="sig-paren">)</span><a class="headerlink" href="#c.os_time_get" title="Permalink to this definition">?</a></dt>
+<dd><p>Get the current OS time in ticks. </p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>OS time in ticks </dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_time_advance">
+<span class="target" id="group___o_s_time_1ga1804fd98423ee3fb364cd7394de12c58"></span>void <code class="descname">os_time_advance</code><span class="sig-paren">(</span>int<em>&nbsp;ticks</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_time_advance" title="Permalink to this definition">?</a></dt>
+<dd><p>Move OS time forward ticks. </p>
+<p><dl class="docutils">
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">ticks</span></code>: The number of ticks to move time forward. </li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_time_delay">
+<span class="target" id="group___o_s_time_1ga7213d633b86da8e00d13061d12a1f075"></span>void <code class="descname">os_time_delay</code><span class="sig-paren">(</span>int32_t<em>&nbsp;osticks</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_time_delay" title="Permalink to this definition">?</a></dt>
+<dd><p>Puts the current task to sleep for the specified number of os ticks. </p>
+<p>There is no delay if ticks is &lt;= 0.</p>
+<p><dl class="docutils">
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">osticks</span></code>: Number of ticks to delay (&lt;= 0 means no delay). </li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_settimeofday">
+<span class="target" id="group___o_s_time_1ga51fe1688dd54af6c0f8f564f4cad2f0e"></span>int <code class="descname">os_settimeofday</code><span class="sig-paren">(</span>struct  os_timeval  *<em>&nbsp;utctime</em>, struct  os_timezone  *<em>&nbsp;tz</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_settimeofday" title="Permalink to this definition">?</a></dt>
+<dd><p>Set the time of day. </p>
+<p>This does not modify os time, but rather just modifies the offset by which we are tracking real time against os time.</p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>0 on success, non-zero on failure. </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">utctime</span></code>: A timeval representing the UTC time we are setting </li>
+<li><code class="docutils literal notranslate"><span class="pre">tz</span></code>: The time-zone to apply against the utctime being set.</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_gettimeofday">
+<span class="target" id="group___o_s_time_1gab552d38ffef88c59f99d40e6c960f10b"></span>int <code class="descname">os_gettimeofday</code><span class="sig-paren">(</span>struct  os_timeval  *<em>&nbsp;utctime</em>, struct  os_timezone  *<em>&nbsp;tz</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_gettimeofday" title="Permalink to this definition">?</a></dt>
+<dd><p>Get the current time of day. </p>
+<p>Returns the time of day in UTC into the tv argument, and returns the timezone (if set) into tz.</p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>0 on success, non-zero on failure </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">tv</span></code>: The structure to put the UTC time of day into </li>
+<li><code class="docutils literal notranslate"><span class="pre">tz</span></code>: The structure to put the timezone information into</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_get_uptime_usec">
+<span class="target" id="group___o_s_time_1ga68328fcd56f96d4af71ad36d6b90abe2"></span>int64_t <code class="descname">os_get_uptime_usec</code><span class="sig-paren">(</span>void<span class="sig-paren">)</span><a class="headerlink" href="#c.os_get_uptime_usec" title="Permalink to this definition">?</a></dt>
+<dd><p>Get time since boot in microseconds. </p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>time since boot in microseconds </dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_time_ms_to_ticks">
+<span class="target" id="group___o_s_time_1gae5d9e53dfa7e8fd721766271ea003ac7"></span>int <code class="descname">os_time_ms_to_ticks</code><span class="sig-paren">(</span>uint32_t<em>&nbsp;ms</em>, uint32_t *<em>&nbsp;out_ticks</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_time_ms_to_ticks" title="Permalink to this definition">?</a></dt>
+<dd><p>Converts milliseconds to OS ticks. </p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>0 on success; OS_EINVAL if the result is too large to fit in a uint32_t. </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">ms</span></code>: The milliseconds input. </li>
+<li><code class="docutils literal notranslate"><span class="pre">out_ticks</span></code>: The OS ticks output.</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="define">
+<dt id="c.OS_TIME_MAX">
+<span class="target" id="group___o_s_time_1ga7d9d6efeb91296092166d7f9e1b82cc3"></span><code class="descname">OS_TIME_MAX</code><a class="headerlink" href="#c.OS_TIME_MAX" title="Permalink to this definition">?</a></dt>
+<dd></dd></dl>
+
+<dl class="define">
+<dt id="c.OS_TIMEOUT_NEVER">
+<span class="target" id="group___o_s_time_1gae28c55062f853e4feb13b3c61a04099c"></span><code class="descname">OS_TIMEOUT_NEVER</code><a class="headerlink" href="#c.OS_TIMEOUT_NEVER" title="Permalink to this definition">?</a></dt>
+<dd></dd></dl>
+
+<dl class="define">
+<dt id="c.OS_TIME_TICK_LT">
+<span class="target" id="group___o_s_time_1ga9ea6181f50d4452091125926891dd6c7"></span><code class="descname">OS_TIME_TICK_LT</code><span class="sig-paren">(</span>__t1, __t2<span class="sig-paren">)</span><a class="headerlink" href="#c.OS_TIME_TICK_LT" title="Permalink to this definition">?</a></dt>
+<dd></dd></dl>
+
+<dl class="define">
+<dt id="c.OS_TIME_TICK_GT">
+<span class="target" id="group___o_s_time_1gacd74602e3bed14014f4e1854aff8bf92"></span><code class="descname">OS_TIME_TICK_GT</code><span class="sig-paren">(</span>__t1, __t2<span class="sig-paren">)</span><a class="headerlink" href="#c.OS_TIME_TICK_GT" title="Permalink to this definition">?</a></dt>
+<dd></dd></dl>
+
+<dl class="define">
+<dt id="c.OS_TIME_TICK_GEQ">
+<span class="target" id="group___o_s_time_1ga3b96d8bc74b2771519ea74c3cc775b58"></span><code class="descname">OS_TIME_TICK_GEQ</code><span class="sig-paren">(</span>__t1, __t2<span class="sig-paren">)</span><a class="headerlink" href="#c.OS_TIME_TICK_GEQ" title="Permalink to this definition">?</a></dt>
+<dd></dd></dl>
+
+<dl class="define">
+<dt id="c.os_timeradd">
+<span class="target" id="group___o_s_time_1ga1e206e1b6cad723bb4bde169cf4f8423"></span><code class="descname">os_timeradd</code><span class="sig-paren">(</span>tvp, uvp, vvp<span class="sig-paren">)</span><a class="headerlink" href="#c.os_timeradd" title="Permalink to this definition">?</a></dt>
+<dd><p>Add first two timeval arguments and place results in third timeval argument. </p>
+</dd></dl>
+
+<dl class="define">
+<dt id="c.os_timersub">
+<span class="target" id="group___o_s_time_1ga9b5b5bf81fac37a92de28d93ec6d0935"></span><code class="descname">os_timersub</code><span class="sig-paren">(</span>tvp, uvp, vvp<span class="sig-paren">)</span><a class="headerlink" href="#c.os_timersub" title="Permalink to this definition">?</a></dt>
+<dd><p>Subtract first two timeval arguments and place results in third timeval argument. </p>
+</dd></dl>
+
+<dl class="class">
+<dt id="_CPPv310os_timeval">
+<span id="_CPPv210os_timeval"></span><span id="os_timeval"></span><span class="target" id="structos__timeval"></span><em class="property">struct </em><code class="descname">os_timeval</code><a class="headerlink" href="#_CPPv310os_timeval" title="Permalink to this definition">?</a><br /></dt>
+<dd><em>#include &lt;os_time.h&gt;</em><p>Structure representing time since Jan 1 1970 with microsecond granularity. </p>
+</dd></dl>
+
+<dl class="class">
+<dt id="_CPPv311os_timezone">
+<span id="_CPPv211os_timezone"></span><span id="os_timezone"></span><span class="target" id="structos__timezone"></span><em class="property">struct </em><code class="descname">os_timezone</code><a class="headerlink" href="#_CPPv311os_timezone" title="Permalink to this definition">?</a><br /></dt>
+<dd><em>#include &lt;os_time.h&gt;</em><p>Structure representing a timezone offset. </p>
+<div class="breathe-sectiondef docutils container">
+<p class="breathe-sectiondef-title rubric">Public Members</p>
+<dl class="variable">
+<dt id="c.os_timezone::tz_minuteswest">
+<span class="target" id="structos__timezone_1aa49a54e62d0e87482130d87c5eab0022"></span>int16_t <code class="descname">tz_minuteswest</code><a class="headerlink" href="#c.os_timezone::tz_minuteswest" title="Permalink to this definition">?</a></dt>
+<dd><p>Minutes west of GMT. </p>
+</dd></dl>
+
+<dl class="variable">
+<dt id="c.os_timezone::tz_dsttime">
+<span class="target" id="structos__timezone_1a2644f6e4558f08da4d94b4dc27d6d5e5"></span>int16_t <code class="descname">tz_dsttime</code><a class="headerlink" href="#c.os_timezone::tz_dsttime" title="Permalink to this definition">?</a></dt>
+<dd><p>Daylight savings time correction (if any) </p>
+</dd></dl>
+
+</div>
+</dd></dl>
+
 </div>
 </div>
 
@@ -417,7 +597,7 @@ <h2><a class="toc-backref" href="#id5">Special Notes</a><a class="headerlink" hr
                   
     <div class="rst-footer-buttons row" role="navigation" aria-label="footer navigation">
       
-        <a href="../task/task.html" class="btn btn-neutral float-right" title="Task" accesskey="n">Next: Task <span class="fa fa-arrow-circle-right"></span></a>
+        <a href="../sanity/sanity.html" class="btn btn-neutral float-right" title="Sanity" accesskey="n">Next: Sanity <span class="fa fa-arrow-circle-right"></span></a>
       
       
         <a href="../cputime/os_cputime.html" class="btn btn-neutral" title="CPU Time" accesskey="p"><span class="fa fa-arrow-circle-left"></span> Previous: CPU Time</a>
diff --git a/develop/os/modules/console/console.html b/develop/os/modules/console/console.html
index fe95c72f5..214b274c8 100644
--- a/develop/os/modules/console/console.html
+++ b/develop/os/modules/console/console.html
@@ -42,8 +42,8 @@
           <link rel="search" title="Search" href="../../../search.html"/>
       <link rel="top" title="Apache Mynewt 1.3.0 documentation" href="../../../index.html"/>
           <link rel="up" title="OS User Guide" href="../../os_user_guide.html"/>
-          <link rel="next" title="System Configuration and Initialization" href="../sysinitconfig/sysinitconfig.html"/>
-          <link rel="prev" title="Porting Mynewt to a new CPU Architecture" href="../../core_os/porting/port_cpu.html"/> 
+          <link rel="next" title="BLE User Guide" href="../../../network/ble/ble_intro.html"/>
+          <link rel="prev" title="Validation and Error Messages" href="../sysinitconfig/sysconfig_error.html"/> 
 
     
     <script src="../../../_static/js/modernizr.min.js"></script>
@@ -222,10 +222,11 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
 <li class="toctree-l1"><a class="reference internal" href="../../../concepts.html">Concepts</a></li>
 <li class="toctree-l1"><a class="reference internal" href="../../../tutorials/tutorials.html">Tutorials</a></li>
 <li class="toctree-l1 current"><a class="reference internal" href="../../os_user_guide.html">OS User Guide</a><ul class="current">
-<li class="toctree-l2"><a class="reference internal" href="../../core_os/mynewt_os.html">OS Core</a></li>
-<li class="toctree-l2"><a class="reference internal" href="../../core_os/porting/port_os.html">Porting Mynewt OS</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../../core_os/mynewt_os.html">Kernel</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../hal/hal.html">Hardware Abstraction</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../../core_os/porting/port_os.html">Porting Guide</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../sysinitconfig/sysinitconfig.html">System Configuration</a></li>
 <li class="toctree-l2 current"><a class="current reference internal" href="#">Console</a></li>
-<li class="toctree-l2"><a class="reference internal" href="../sysinitconfig/sysinitconfig.html">System Configuration and Initialization</a></li>
 </ul>
 </li>
 <li class="toctree-l1"><a class="reference internal" href="../../../network/ble/ble_intro.html">BLE User Guide</a></li>
@@ -664,10 +665,10 @@ <h2><a class="toc-backref" href="#id9">API</a><a class="headerlink" href="#api"
                   
     <div class="rst-footer-buttons row" role="navigation" aria-label="footer navigation">
       
-        <a href="../sysinitconfig/sysinitconfig.html" class="btn btn-neutral float-right" title="System Configuration and Initialization" accesskey="n">Next: System Configuration and Initialization <span class="fa fa-arrow-circle-right"></span></a>
+        <a href="../../../network/ble/ble_intro.html" class="btn btn-neutral float-right" title="BLE User Guide" accesskey="n">Next: BLE User Guide <span class="fa fa-arrow-circle-right"></span></a>
       
       
-        <a href="../../core_os/porting/port_cpu.html" class="btn btn-neutral" title="Porting Mynewt to a new CPU Architecture" accesskey="p"><span class="fa fa-arrow-circle-left"></span> Previous: Porting Mynewt to a new CPU Architecture</a>
+        <a href="../sysinitconfig/sysconfig_error.html" class="btn btn-neutral" title="Validation and Error Messages" accesskey="p"><span class="fa fa-arrow-circle-left"></span> Previous: Validation and Error Messages</a>
       
     </div>
 
diff --git a/develop/os/modules/hal/hal.html b/develop/os/modules/hal/hal.html
index 7f37e820e..91ce6594d 100644
--- a/develop/os/modules/hal/hal.html
+++ b/develop/os/modules/hal/hal.html
@@ -40,7 +40,10 @@
           <link rel="index" title="Index"
                 href="../../../genindex.html"/>
           <link rel="search" title="Search" href="../../../search.html"/>
-      <link rel="top" title="Apache Mynewt 1.3.0 documentation" href="../../../index.html"/> 
+      <link rel="top" title="Apache Mynewt 1.3.0 documentation" href="../../../index.html"/>
+          <link rel="up" title="OS User Guide" href="../../os_user_guide.html"/>
+          <link rel="next" title="Timer" href="hal_timer/hal_timer.html"/>
+          <link rel="prev" title="Sanity" href="../../core_os/sanity/sanity.html"/> 
 
     
     <script src="../../../_static/js/modernizr.min.js"></script>
@@ -151,6 +154,8 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
   <div class="container">
     <a href="/documentation/">Docs</a> /
     
+      <a href="../../os_user_guide.html">OS User Guide</a> /
+    
     Hardware Abstraction Layer
     
   <div class="sourcelink">
@@ -211,12 +216,29 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
       
         
         
-            <ul>
+            <ul class="current">
 <li class="toctree-l1"><a class="reference internal" href="../../../index.html">Introduction</a></li>
 <li class="toctree-l1"><a class="reference internal" href="../../../get_started/index.html">Setup &amp; Get Started</a></li>
 <li class="toctree-l1"><a class="reference internal" href="../../../concepts.html">Concepts</a></li>
 <li class="toctree-l1"><a class="reference internal" href="../../../tutorials/tutorials.html">Tutorials</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../os_user_guide.html">OS User Guide</a></li>
+<li class="toctree-l1 current"><a class="reference internal" href="../../os_user_guide.html">OS User Guide</a><ul class="current">
+<li class="toctree-l2"><a class="reference internal" href="../../core_os/mynewt_os.html">Kernel</a></li>
+<li class="toctree-l2 current"><a class="current reference internal" href="#">Hardware Abstraction</a><ul>
+<li class="toctree-l3"><a class="reference internal" href="hal_timer/hal_timer.html">Timer</a></li>
+<li class="toctree-l3"><a class="reference internal" href="hal_gpio/hal_gpio.html">GPIO</a></li>
+<li class="toctree-l3"><a class="reference internal" href="hal_uart/hal_uart.html">UART</a></li>
+<li class="toctree-l3"><a class="reference internal" href="hal_spi/hal_spi.html">SPI</a></li>
+<li class="toctree-l3"><a class="reference internal" href="hal_i2c/hal_i2c.html">I2C</a></li>
+<li class="toctree-l3"><a class="reference internal" href="hal_flash/hal_flash.html">Flash</a></li>
+<li class="toctree-l3"><a class="reference internal" href="hal_watchdog/hal_watchdog.html">Watchdog</a></li>
+<li class="toctree-l3"><a class="reference internal" href="hal_bsp/hal_bsp.html">BSP</a></li>
+</ul>
+</li>
+<li class="toctree-l2"><a class="reference internal" href="../../core_os/porting/port_os.html">Porting Guide</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../sysinitconfig/sysinitconfig.html">System Configuration</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../console/console.html">Console</a></li>
+</ul>
+</li>
 <li class="toctree-l1"><a class="reference internal" href="../../../network/ble/ble_intro.html">BLE User Guide</a></li>
 <li class="toctree-l1"><a class="reference internal" href="../../../newt/index.html">Newt Tool Guide</a></li>
 <li class="toctree-l1"><a class="reference internal" href="../../../newtmgr/index.html">Newt Manager Guide</a></li>
@@ -250,6 +272,8 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
                     
   <div class="section" id="hardware-abstraction-layer">
 <h1>Hardware Abstraction Layer<a class="headerlink" href="#hardware-abstraction-layer" title="Permalink to this headline">?</a></h1>
+<div class="toctree-wrapper compound">
+</div>
 <div class="section" id="description">
 <h2>Description<a class="headerlink" href="#description" title="Permalink to this headline">?</a></h2>
 <p>The Hardware Abstraction Layer (HAL) in Mynewt is a low-level, base
@@ -339,6 +363,15 @@ <h2>Platform Support<a class="headerlink" href="#platform-support" title="Permal
                    </div>
                   </div>
                   
+    <div class="rst-footer-buttons row" role="navigation" aria-label="footer navigation">
+      
+        <a href="hal_timer/hal_timer.html" class="btn btn-neutral float-right" title="Timer" accesskey="n">Next: Timer <span class="fa fa-arrow-circle-right"></span></a>
+      
+      
+        <a href="../../core_os/sanity/sanity.html" class="btn btn-neutral" title="Sanity" accesskey="p"><span class="fa fa-arrow-circle-left"></span> Previous: Sanity</a>
+      
+    </div>
+
                 </div>
               </div>
             </div>
diff --git a/develop/os/modules/hal/hal_api.html b/develop/os/modules/hal/hal_api.html
deleted file mode 100644
index dcca0a0e5..000000000
--- a/develop/os/modules/hal/hal_api.html
+++ /dev/null
@@ -1,317 +0,0 @@
-
-
-<!DOCTYPE html>
-<html lang="en">
-  <head>
-    <meta charset="utf-8">
-    <meta http-equiv="X-UA-Compatible" content="IE=edge">
-    <meta name="viewport" content="width=device-width, initial-scale=1.0">
-
-    
-
-    
-    <title>HAL Interfaces &mdash; Apache Mynewt 1.3.0 documentation</title>
-    
-
-    
-    
-      <link rel="shortcut icon" href="../../../_static/mynewt-logo-only-newt32x32.png"/>
-    
-
-    
-
-    <link rel="stylesheet" href="../../../_static/css/theme.css" type="text/css" />
-
-    
-      <link rel="stylesheet" href="../../../_static/css/sphinx_theme.css" type="text/css" />
-    
-      <link rel="stylesheet" href="../../../_static/css/bootstrap-3.0.3.min.css" type="text/css" />
-    
-      <link rel="stylesheet" href="../../../_static/css/v2.css" type="text/css" />
-    
-      <link rel="stylesheet" href="../../../_static/css/custom.css" type="text/css" />
-    
-      <link rel="stylesheet" href="../../../_static/css/restructuredtext.css" type="text/css" />
-    
-
-    
-
-    <link rel="stylesheet" href="../../../_static/css/overrides.css" type="text/css" />
-          <link rel="index" title="Index"
-                href="../../../genindex.html"/>
-          <link rel="search" title="Search" href="../../../search.html"/>
-      <link rel="top" title="Apache Mynewt 1.3.0 documentation" href="../../../index.html"/> 
-
-    
-    <script src="../../../_static/js/modernizr.min.js"></script>
-
-    
-    <script>
-    (function(i, s, o, g, r, a, m) {
-	i["GoogleAnalyticsObject"] = r;
-	(i[r] =
-		i[r] ||
-		function() {
-			(i[r].q = i[r].q || []).push(arguments);
-		}),
-		(i[r].l = 1 * new Date());
-	(a = s.createElement(o)), (m = s.getElementsByTagName(o)[0]);
-	a.async = 1;
-	a.src = g;
-	m.parentNode.insertBefore(a, m);
-})(window, document, "script", "//www.google-analytics.com/analytics.js", "ga");
-
-ga("create", "UA-72162311-1", "auto");
-ga("send", "pageview");
-</script>
-    
-
-  </head>
-
-  <body class="not-front page-documentation" role="document" >
-    <div id="wrapper">
-      <div class="container">
-    <div id="banner" class="row v2-main-banner">
-        <a class="logo-cell" href="/">
-            <img class="logo" src="../../../_static/img/logo.png">
-        </a>
-        <div class="tagline-cell">
-            <h4 class="tagline">An OS to build, deploy and securely manage billions of devices</h4>
-        </div>
-        <div class="news-cell">
-            <div class="well">
-              <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (December 13, 2017)
-            </div>
-        </div>
-    </div>
-</div>
-      
-<header>
-    <nav id="navbar" class="navbar navbar-inverse" role="navigation">
-        <div class="container">
-            <!-- Collapsed navigation -->
-            <div class="navbar-header">
-                <!-- Expander button -->
-                <button type="button" class="navbar-toggle" data-toggle="collapse" data-target=".navbar-collapse">
-                    <span class="sr-only">Toggle navigation</span>
-                    <span class="icon-bar"></span>
-                    <span class="icon-bar"></span>
-                    <span class="icon-bar"></span>
-                </button>
-
-            </div>
-
-            <!-- Expanded navigation -->
-            <div class="navbar-collapse collapse">
-                <!-- Main navigation -->
-                <ul class="nav navbar-nav navbar-right">
-                    <li>
-                        <a href="/"><i class="fa fa-home" style="font-size: larger;"></i></a>
-                    </li>
-                    <li class="important">
-                        <a href="/get_started/quick_start.html">Quick Start</a>
-                    </li>
-                    <li>
-                        <a href="/about/">About</a>
-                    </li>
-                    <li>
-                        <a href="/talks/">Talks</a>
-                    </li>
-                    <li class="active">
-                        <a href="/documentation/">Documentation</a>
-                    </li>
-                    <li>
-                        <a href="/download/">Download</a>
-                    </li>
-                    <li>
-                        <a href="/community/">Community</a>
-                    </li>
-                    <li>
-                        <a href="/events/">Events</a>
-                    </li>
-                </ul>
-
-                <!-- Search, Navigation and Repo links -->
-                <ul class="nav navbar-nav navbar-right">
-                    
-                </ul>
-            </div>
-        </div>
-    </nav>
-</header>
-      <!-- STARTS MAIN CONTENT -->
-      <div id="main-content">
-        
-
-
-
-
-
-<div id="breadcrumb">
-  <div class="container">
-    <a href="/documentation/">Docs</a> /
-    
-    HAL Interfaces
-    
-  <div class="sourcelink">
-    <a href="https://github.com/apache/mynewt-core/edit/master/docs/os/modules/hal/hal_api.rst" class="icon icon-github"
-           rel="nofollow"> Edit on GitHub</a>
-</div>
-  </div>
-</div>
-        <!-- STARTS CONTAINER -->
-        <div class="container">
-          <!-- STARTS .content -->
-          <div id="content" class="row">
-            
-            <!-- STARTS .container-sidebar -->
-<div class="container-sidebar col-xs-12 col-sm-3">
-  <div id="docSidebar" class="sticky-container">
-    <div role="search" class="sphinx-search">
-  <form id="rtd-search-form" class="wy-form" action="../../../search.html" method="get">
-    <input type="text" name="q" placeholder="Search documentation" class="search-documentation" />
-    <input type="hidden" name="check_keywords" value="yes" />
-    <input type="hidden" name="area" value="default" />
-  </form>
-</div>
-    
-<!-- Note: only works when deployed -->
-<select class="form-control" onchange="if (this.value) window.location.href=this.value">
-    <option
-      value="/develop"
-      selected
-      >
-      Version: develop (latest - mynewt-documentation)
-    </option>
-    <option
-      value="/latest/os/introduction"
-      >
-      Version: master (latest - mynewt-site)
-    </option>
-    <option
-      value="/v1_2_0/os/introduction"
-      >
-      Version: 1.2.0
-    </option>
-    <option
-      value="/v1_1_0/os/introduction">
-      Version: 1.1.0
-    </option>
-    <option
-      value="/v1_0_0/os/introduction">
-      Version: 1.0.0
-    </option>
-    <option
-      value="/v0_9_0/os/introduction">
-      Version: 0_9_0
-    </option>
-</select>
-    <div class="region region-sidebar">
-      <div class="docs-menu">
-      
-        
-        
-            <ul>
-<li class="toctree-l1"><a class="reference internal" href="../../../index.html">Introduction</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../../get_started/index.html">Setup &amp; Get Started</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../../concepts.html">Concepts</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../../tutorials/tutorials.html">Tutorials</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../os_user_guide.html">OS User Guide</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../../network/ble/ble_intro.html">BLE User Guide</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../../newt/index.html">Newt Tool Guide</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../../newtmgr/index.html">Newt Manager Guide</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../../misc/index.html">Appendix</a></li>
-</ul>
-
-        
-      
-      </div>
-    </div>
-  </div>
-  <!-- ENDS STICKY CONTAINER -->
-</div>
-<!-- ENDS .container-sidebar -->
-
-            <div class="col-xs-12 col-sm-9">
-              <div class="alert alert-info" role="alert">
-  <p>
-    This is the development version of Apache Mynewt documentation. As such it may not be as complete as the latest
-    stable version of the documentation found <a href="/latest/os/introduction/">here</a>.
-  </p>
-  <p>
-    To improve this documentation please visit <a href="https://github.com/apache/mynewt-documentation">https://github.com/apache/mynewt-documentation</a>.
-  </p>
-</div>
-              
-              <div class="">
-                <div class="rst-content">
-                  <div role="main" class="document" itemscope="itemscope" itemtype="http://schema.org/Article">
-                   <div itemprop="articleBody">
-                    
-  <div class="section" id="hal-interfaces">
-<h1>HAL Interfaces<a class="headerlink" href="#hal-interfaces" title="Permalink to this headline">?</a></h1>
-<p>The HAL supports separate interfaces for many peripherals. A brief
-description of the interfaces are shown below.</p>
-</div>
-
-
-                   </div>
-                  </div>
-                  
-                </div>
-              </div>
-            </div>
-            <!-- ENDS CONTENT SECTION -->
-          </div>
-          <!-- ENDS .content -->
-        </div>
-      </div>
-      <footer>
-  <div class="container">
-    <div class="row">
-      <div class="col-xs-12">
-          
-              <p class="copyright">Apache Mynewt is available under Apache License, version 2.0.</p>
-          
-      </div>
-      <div class="col-xs-12">
-          <div class="logos">
-              <img src="../../../_static/img/asf_logo_wide_small.png" alt="Apache" title="Apache">
-              <small class="footnote">
-                Apache Mynewt, Mynewt, Apache, the Apache feather logo, and the Apache Mynewt project logo are either
-                registered trademarks or trademarks of the Apache Software Foundation in the United States and other countries.
-              </small>
-              <a href="https://join.slack.com/mynewt/shared_invite/MTkwMTg1ODM1NTg5LTE0OTYxNzQ4NzQtZTU1YmNhYjhkMg">
-                <img src="../../../_static/img/add_to_slack.png" alt="Slack Icon" title="Join our Slack Community" />
-              </a>
-          </div>
-      </div>
-    </div>
-  </div>
-</footer>
-    </div>
-    <!-- ENDS #wrapper -->
-
-  
-
-    <script type="text/javascript">
-        var DOCUMENTATION_OPTIONS = {
-            URL_ROOT:'../../../',
-            VERSION:'1.3.0',
-            COLLAPSE_INDEX:false,
-            FILE_SUFFIX:'.html',
-            HAS_SOURCE:  true,
-            SOURCELINK_SUFFIX: '.txt'
-        };
-    </script>
-      <script type="text/javascript" src="../../../_static/jquery.js"></script>
-      <script type="text/javascript" src="../../../_static/underscore.js"></script>
-      <script type="text/javascript" src="../../../_static/doctools.js"></script>
-      <script type="text/javascript" src="../../../_static/js/bootstrap-3.0.3.min.js"></script>
-      <script type="text/javascript" src="../../../_static/js/affix.js"></script>
-      <script type="text/javascript" src="../../../_static/js/main.js"></script>
-
-   
-
-  </body>
-</html>
\ No newline at end of file
diff --git a/develop/os/modules/hal/hal_bsp/hal_bsp.html b/develop/os/modules/hal/hal_bsp/hal_bsp.html
index 0acb6e3f3..d1a70f408 100644
--- a/develop/os/modules/hal/hal_bsp/hal_bsp.html
+++ b/develop/os/modules/hal/hal_bsp/hal_bsp.html
@@ -10,7 +10,7 @@
     
 
     
-    <title>hal_bsp &mdash; Apache Mynewt 1.3.0 documentation</title>
+    <title>BSP &mdash; Apache Mynewt 1.3.0 documentation</title>
     
 
     
@@ -40,7 +40,10 @@
           <link rel="index" title="Index"
                 href="../../../../genindex.html"/>
           <link rel="search" title="Search" href="../../../../search.html"/>
-      <link rel="top" title="Apache Mynewt 1.3.0 documentation" href="../../../../index.html"/> 
+      <link rel="top" title="Apache Mynewt 1.3.0 documentation" href="../../../../index.html"/>
+          <link rel="up" title="Hardware Abstraction Layer" href="../hal.html"/>
+          <link rel="next" title="Porting Mynewt OS" href="../../../core_os/porting/port_os.html"/>
+          <link rel="prev" title="Watchdog" href="../hal_watchdog/hal_watchdog.html"/> 
 
     
     <script src="../../../../_static/js/modernizr.min.js"></script>
@@ -151,7 +154,11 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
   <div class="container">
     <a href="/documentation/">Docs</a> /
     
-    hal_bsp
+      <a href="../../../os_user_guide.html">OS User Guide</a> /
+    
+      <a href="../hal.html">Hardware Abstraction Layer</a> /
+    
+    BSP
     
   <div class="sourcelink">
     <a href="https://github.com/apache/mynewt-core/edit/master/docs/os/modules/hal/hal_bsp/hal_bsp.rst" class="icon icon-github"
@@ -211,12 +218,29 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
       
         
         
-            <ul>
+            <ul class="current">
 <li class="toctree-l1"><a class="reference internal" href="../../../../index.html">Introduction</a></li>
 <li class="toctree-l1"><a class="reference internal" href="../../../../get_started/index.html">Setup &amp; Get Started</a></li>
 <li class="toctree-l1"><a class="reference internal" href="../../../../concepts.html">Concepts</a></li>
 <li class="toctree-l1"><a class="reference internal" href="../../../../tutorials/tutorials.html">Tutorials</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../../os_user_guide.html">OS User Guide</a></li>
+<li class="toctree-l1 current"><a class="reference internal" href="../../../os_user_guide.html">OS User Guide</a><ul class="current">
+<li class="toctree-l2"><a class="reference internal" href="../../../core_os/mynewt_os.html">Kernel</a></li>
+<li class="toctree-l2 current"><a class="reference internal" href="../hal.html">Hardware Abstraction</a><ul class="current">
+<li class="toctree-l3"><a class="reference internal" href="../hal_timer/hal_timer.html">Timer</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../hal_gpio/hal_gpio.html">GPIO</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../hal_uart/hal_uart.html">UART</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../hal_spi/hal_spi.html">SPI</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../hal_i2c/hal_i2c.html">I2C</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../hal_flash/hal_flash.html">Flash</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../hal_watchdog/hal_watchdog.html">Watchdog</a></li>
+<li class="toctree-l3 current"><a class="current reference internal" href="#">BSP</a></li>
+</ul>
+</li>
+<li class="toctree-l2"><a class="reference internal" href="../../../core_os/porting/port_os.html">Porting Guide</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../../sysinitconfig/sysinitconfig.html">System Configuration</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../../console/console.html">Console</a></li>
+</ul>
+</li>
 <li class="toctree-l1"><a class="reference internal" href="../../../../network/ble/ble_intro.html">BLE User Guide</a></li>
 <li class="toctree-l1"><a class="reference internal" href="../../../../newt/index.html">Newt Tool Guide</a></li>
 <li class="toctree-l1"><a class="reference internal" href="../../../../newtmgr/index.html">Newt Manager Guide</a></li>
@@ -248,8 +272,8 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
                   <div role="main" class="document" itemscope="itemscope" itemtype="http://schema.org/Article">
                    <div itemprop="articleBody">
                     
-  <div class="section" id="hal-bsp">
-<h1>hal_bsp<a class="headerlink" href="#hal-bsp" title="Permalink to this headline">?</a></h1>
+  <div class="section" id="bsp">
+<h1>BSP<a class="headerlink" href="#bsp" title="Permalink to this headline">?</a></h1>
 <p>This is the hardware independent BSP (Board Support Package) Interface
 for Mynewt.</p>
 <div class="section" id="description">
@@ -257,13 +281,119 @@ <h2>Description<a class="headerlink" href="#description" title="Permalink to thi
 <p>Contains the basic operations to initialize, specify memory to include
 in coredump, configure interrupt priority etc.</p>
 </div>
-<div class="section" id="definition">
-<h2>Definition<a class="headerlink" href="#definition" title="Permalink to this headline">?</a></h2>
-<p><a class="reference external" href="https://github.com/apache/incubator-mynewt-core/blob/master/hw/hal/include/hal/hal_bsp.h">hal_bsp.h</a></p>
-</div>
-<div class="section" id="examples">
-<h2>Examples<a class="headerlink" href="#examples" title="Permalink to this headline">?</a></h2>
-<hr class="docutils" />
+<div class="section" id="api">
+<h2>API<a class="headerlink" href="#api" title="Permalink to this headline">?</a></h2>
+<dl class="function">
+<dt id="c.hal_bsp_init">
+<span class="target" id="group___h_a_l_bsp_1ga4ad418f1deb118d693cc9c0535b8ace6"></span>void <code class="descname">hal_bsp_init</code><span class="sig-paren">(</span>void<span class="sig-paren">)</span><a class="headerlink" href="#c.hal_bsp_init" title="Permalink to this definition">?</a></dt>
+<dd><p>Initializes BSP; registers flash_map with the system. </p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.hal_bsp_flash_dev">
+<span class="target" id="group___h_a_l_bsp_1ga4fa424de0d3540a39799fb2cd299437c"></span>const struct hal_flash* <code class="descname">hal_bsp_flash_dev</code><span class="sig-paren">(</span>uint8_t<em>&nbsp;flash_id</em><span class="sig-paren">)</span><a class="headerlink" href="#c.hal_bsp_flash_dev" title="Permalink to this definition">?</a></dt>
+<dd></dd></dl>
+
+<dl class="function">
+<dt id="c._sbrk">
+<span class="target" id="group___h_a_l_bsp_1ga53794c5117195586a0b3d4ee7be2f458"></span>void* <code class="descname">_sbrk</code><span class="sig-paren">(</span>int<em>&nbsp;incr</em><span class="sig-paren">)</span><a class="headerlink" href="#c._sbrk" title="Permalink to this definition">?</a></dt>
+<dd></dd></dl>
+
+<dl class="function">
+<dt id="c.hal_bsp_core_dump">
+<span class="target" id="group___h_a_l_bsp_1ga824160e76268adf7a498fc5c5c8314a0"></span>const struct hal_bsp_mem_dump* <code class="descname">hal_bsp_core_dump</code><span class="sig-paren">(</span>int *<em>&nbsp;area_cnt</em><span class="sig-paren">)</span><a class="headerlink" href="#c.hal_bsp_core_dump" title="Permalink to this definition">?</a></dt>
+<dd><p>Report which memory areas should be included inside a coredump. </p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.hal_bsp_hw_id">
+<span class="target" id="group___h_a_l_bsp_1gab42bbe00ac53e2af4f9e6b00f008546f"></span>int <code class="descname">hal_bsp_hw_id</code><span class="sig-paren">(</span>uint8_t *<em>&nbsp;id</em>, int<em>&nbsp;max_len</em><span class="sig-paren">)</span><a class="headerlink" href="#c.hal_bsp_hw_id" title="Permalink to this definition">?</a></dt>
+<dd><p>Get unique HW identifier/serial number for platform. </p>
+<p>Returns the number of bytes filled in.</p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>0 on success, non-zero error code on failure </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">id</span></code>: Pointer to the ID to fill out </li>
+<li><code class="docutils literal notranslate"><span class="pre">max_len</span></code>: Maximum length to fill into the ID</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.hal_bsp_power_state">
+<span class="target" id="group___h_a_l_bsp_1ga612a6b38f8eb778131ae2c28cae87213"></span>int <code class="descname">hal_bsp_power_state</code><span class="sig-paren">(</span>int<em>&nbsp;state</em><span class="sig-paren">)</span><a class="headerlink" href="#c.hal_bsp_power_state" title="Permalink to this definition">?</a></dt>
+<dd><p>Move the system into the specified power state. </p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>0 on success, non-zero if system cannot move into this power state. </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">state</span></code>: The power state to move the system into, this is one of<ul>
+<li>HAL_BSP_POWER_ON: Full system on</li>
+<li>HAL_BSP_POWER_WFI: Processor off, wait for interrupt.</li>
+<li>HAL_BSP_POWER_SLEEP: Put the system to sleep</li>
+<li>HAL_BSP_POWER_DEEP_SLEEP: Put the system into deep sleep.</li>
+<li>HAL_BSP_POWER_OFF: Turn off the system.</li>
+<li>HAL_BSP_POWER_PERUSER: From this value on, allow user defined power states.</li>
+</ul>
+</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.hal_bsp_get_nvic_priority">
+<span class="target" id="group___h_a_l_bsp_1ga123acf94924f2c8e9e70cf34bf4e272b"></span>uint32_t <code class="descname">hal_bsp_get_nvic_priority</code><span class="sig-paren">(</span>int<em>&nbsp;irq_num</em>, uint32_t<em>&nbsp;pri</em><span class="sig-paren">)</span><a class="headerlink" href="#c.hal_bsp_get_nvic_priority" title="Permalink to this definition">?</a></dt>
+<dd><p>Returns priority of given interrupt number. </p>
+</dd></dl>
+
+<dl class="define">
+<dt id="c.HAL_BSP_MAX_ID_LEN">
+<span class="target" id="group___h_a_l_bsp_1gaf791784d809663178cefba9d227952b1"></span><code class="descname">HAL_BSP_MAX_ID_LEN</code><a class="headerlink" href="#c.HAL_BSP_MAX_ID_LEN" title="Permalink to this definition">?</a></dt>
+<dd></dd></dl>
+
+<dl class="define">
+<dt id="c.HAL_BSP_POWER_ON">
+<span class="target" id="group___h_a_l_bsp_1ga4975e9239b707571069a038056cb1369"></span><code class="descname">HAL_BSP_POWER_ON</code><a class="headerlink" href="#c.HAL_BSP_POWER_ON" title="Permalink to this definition">?</a></dt>
+<dd><p>Full System On. </p>
+</dd></dl>
+
+<dl class="define">
+<dt id="c.HAL_BSP_POWER_WFI">
+<span class="target" id="group___h_a_l_bsp_1gadc7a0386af363256bafc1f6864ae9565"></span><code class="descname">HAL_BSP_POWER_WFI</code><a class="headerlink" href="#c.HAL_BSP_POWER_WFI" title="Permalink to this definition">?</a></dt>
+<dd><p>Wait for Interrupt: CPU off. </p>
+</dd></dl>
+
+<dl class="define">
+<dt id="c.HAL_BSP_POWER_SLEEP">
+<span class="target" id="group___h_a_l_bsp_1gaa8e79fea75be93be6d631657ce9050fd"></span><code class="descname">HAL_BSP_POWER_SLEEP</code><a class="headerlink" href="#c.HAL_BSP_POWER_SLEEP" title="Permalink to this definition">?</a></dt>
+<dd><p>System sleep mode, processor off, some peripherals off too. </p>
+</dd></dl>
+
+<dl class="define">
+<dt id="c.HAL_BSP_POWER_DEEP_SLEEP">
+<span class="target" id="group___h_a_l_bsp_1gaf1cbd86f50add269a2169ad66458c352"></span><code class="descname">HAL_BSP_POWER_DEEP_SLEEP</code><a class="headerlink" href="#c.HAL_BSP_POWER_DEEP_SLEEP" title="Permalink to this definition">?</a></dt>
+<dd><p>Deep sleep: possible loss of RAM retention, system wakes up in undefined state. </p>
+</dd></dl>
+
+<dl class="define">
+<dt id="c.HAL_BSP_POWER_OFF">
+<span class="target" id="group___h_a_l_bsp_1ga9e48389b515502742a13a876c8fd962b"></span><code class="descname">HAL_BSP_POWER_OFF</code><a class="headerlink" href="#c.HAL_BSP_POWER_OFF" title="Permalink to this definition">?</a></dt>
+<dd><p>System powering off. </p>
+</dd></dl>
+
+<dl class="define">
+<dt id="c.HAL_BSP_POWER_PERUSER">
+<span class="target" id="group___h_a_l_bsp_1ga08db56673983a9650a2ace6de701169a"></span><code class="descname">HAL_BSP_POWER_PERUSER</code><a class="headerlink" href="#c.HAL_BSP_POWER_PERUSER" title="Permalink to this definition">?</a></dt>
+<dd><p>Per-user power state, base number for user to define custom power states. </p>
+</dd></dl>
+
 </div>
 </div>
 
@@ -271,6 +401,15 @@ <h2>Examples<a class="headerlink" href="#examples" title="Permalink to this head
                    </div>
                   </div>
                   
+    <div class="rst-footer-buttons row" role="navigation" aria-label="footer navigation">
+      
+        <a href="../../../core_os/porting/port_os.html" class="btn btn-neutral float-right" title="Porting Mynewt OS" accesskey="n">Next: Porting Mynewt OS <span class="fa fa-arrow-circle-right"></span></a>
+      
+      
+        <a href="../hal_watchdog/hal_watchdog.html" class="btn btn-neutral" title="Watchdog" accesskey="p"><span class="fa fa-arrow-circle-left"></span> Previous: Watchdog</a>
+      
+    </div>
+
                 </div>
               </div>
             </div>
diff --git a/develop/os/modules/hal/hal_flash/hal_flash.html b/develop/os/modules/hal/hal_flash/hal_flash.html
index 5a2adb2cd..54f71740c 100644
--- a/develop/os/modules/hal/hal_flash/hal_flash.html
+++ b/develop/os/modules/hal/hal_flash/hal_flash.html
@@ -10,7 +10,7 @@
     
 
     
-    <title>hal_flash &mdash; Apache Mynewt 1.3.0 documentation</title>
+    <title>Flash &mdash; Apache Mynewt 1.3.0 documentation</title>
     
 
     
@@ -40,7 +40,10 @@
           <link rel="index" title="Index"
                 href="../../../../genindex.html"/>
           <link rel="search" title="Search" href="../../../../search.html"/>
-      <link rel="top" title="Apache Mynewt 1.3.0 documentation" href="../../../../index.html"/> 
+      <link rel="top" title="Apache Mynewt 1.3.0 documentation" href="../../../../index.html"/>
+          <link rel="up" title="Hardware Abstraction Layer" href="../hal.html"/>
+          <link rel="next" title="Watchdog" href="../hal_watchdog/hal_watchdog.html"/>
+          <link rel="prev" title="I2C" href="../hal_i2c/hal_i2c.html"/> 
 
     
     <script src="../../../../_static/js/modernizr.min.js"></script>
@@ -151,7 +154,11 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
   <div class="container">
     <a href="/documentation/">Docs</a> /
     
-    hal_flash
+      <a href="../../../os_user_guide.html">OS User Guide</a> /
+    
+      <a href="../hal.html">Hardware Abstraction Layer</a> /
+    
+    Flash
     
   <div class="sourcelink">
     <a href="https://github.com/apache/mynewt-core/edit/master/docs/os/modules/hal/hal_flash/hal_flash.rst" class="icon icon-github"
@@ -211,12 +218,29 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
       
         
         
-            <ul>
+            <ul class="current">
 <li class="toctree-l1"><a class="reference internal" href="../../../../index.html">Introduction</a></li>
 <li class="toctree-l1"><a class="reference internal" href="../../../../get_started/index.html">Setup &amp; Get Started</a></li>
 <li class="toctree-l1"><a class="reference internal" href="../../../../concepts.html">Concepts</a></li>
 <li class="toctree-l1"><a class="reference internal" href="../../../../tutorials/tutorials.html">Tutorials</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../../os_user_guide.html">OS User Guide</a></li>
+<li class="toctree-l1 current"><a class="reference internal" href="../../../os_user_guide.html">OS User Guide</a><ul class="current">
+<li class="toctree-l2"><a class="reference internal" href="../../../core_os/mynewt_os.html">Kernel</a></li>
+<li class="toctree-l2 current"><a class="reference internal" href="../hal.html">Hardware Abstraction</a><ul class="current">
+<li class="toctree-l3"><a class="reference internal" href="../hal_timer/hal_timer.html">Timer</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../hal_gpio/hal_gpio.html">GPIO</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../hal_uart/hal_uart.html">UART</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../hal_spi/hal_spi.html">SPI</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../hal_i2c/hal_i2c.html">I2C</a></li>
+<li class="toctree-l3 current"><a class="current reference internal" href="#">Flash</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../hal_watchdog/hal_watchdog.html">Watchdog</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../hal_bsp/hal_bsp.html">BSP</a></li>
+</ul>
+</li>
+<li class="toctree-l2"><a class="reference internal" href="../../../core_os/porting/port_os.html">Porting Guide</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../../sysinitconfig/sysinitconfig.html">System Configuration</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../../console/console.html">Console</a></li>
+</ul>
+</li>
 <li class="toctree-l1"><a class="reference internal" href="../../../../network/ble/ble_intro.html">BLE User Guide</a></li>
 <li class="toctree-l1"><a class="reference internal" href="../../../../newt/index.html">Newt Tool Guide</a></li>
 <li class="toctree-l1"><a class="reference internal" href="../../../../newtmgr/index.html">Newt Manager Guide</a></li>
@@ -248,8 +272,8 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
                   <div role="main" class="document" itemscope="itemscope" itemtype="http://schema.org/Article">
                    <div itemprop="articleBody">
                     
-  <div class="section" id="hal-flash">
-<h1>hal_flash<a class="headerlink" href="#hal-flash" title="Permalink to this headline">?</a></h1>
+  <div class="section" id="flash">
+<h1>Flash<a class="headerlink" href="#flash" title="Permalink to this headline">?</a></h1>
 <p>The hardware independent interface to flash memory that is used by
 applications.</p>
 <div class="section" id="description">
@@ -257,12 +281,43 @@ <h2>Description<a class="headerlink" href="#description" title="Permalink to thi
 <p>The API offers basic initialization, read, write, erase, sector erase,
 and other operations.</p>
 </div>
-<div class="section" id="definition">
-<h2>Definition<a class="headerlink" href="#definition" title="Permalink to this headline">?</a></h2>
-<p><a class="reference external" href="https://github.com/apache/incubator-mynewt-core/blob/master/hw/hal/include/hal/hal_flash.h">hal_flash.h</a></p>
-</div>
-<div class="section" id="examples">
-<h2>Examples<a class="headerlink" href="#examples" title="Permalink to this headline">?</a></h2>
+<div class="section" id="api">
+<h2>API<a class="headerlink" href="#api" title="Permalink to this headline">?</a></h2>
+<dl class="function">
+<dt id="c.hal_flash_ioctl">
+<span class="target" id="group___h_a_l_flash_1ga83c52b5bc0db02dac40effe1275613bc"></span>int <code class="descname">hal_flash_ioctl</code><span class="sig-paren">(</span>uint8_t<em>&nbsp;flash_id</em>, uint32_t<em>&nbsp;cmd</em>, void *<em>&nbsp;args</em><span class="sig-paren">)</span><a class="headerlink" href="#c.hal_flash_ioctl" title="Permalink to this definition">?</a></dt>
+<dd></dd></dl>
+
+<dl class="function">
+<dt id="c.hal_flash_read">
+<span class="target" id="group___h_a_l_flash_1gab52a043a8dc3b929f40f356c50b46e84"></span>int <code class="descname">hal_flash_read</code><span class="sig-paren">(</span>uint8_t<em>&nbsp;flash_id</em>, uint32_t<em>&nbsp;address</em>, void *<em>&nbsp;dst</em>, uint32_t<em>&nbsp;num_bytes</em><span class="sig-paren">)</span><a class="headerlink" href="#c.hal_flash_read" title="Permalink to this definition">?</a></dt>
+<dd></dd></dl>
+
+<dl class="function">
+<dt id="c.hal_flash_write">
+<span class="target" id="group___h_a_l_flash_1gac08fc3f0c55c2e15f3249af4a16f85ae"></span>int <code class="descname">hal_flash_write</code><span class="sig-paren">(</span>uint8_t<em>&nbsp;flash_id</em>, uint32_t<em>&nbsp;address</em>, const void *<em>&nbsp;src</em>, uint32_t<em>&nbsp;num_bytes</em><span class="sig-paren">)</span><a class="headerlink" href="#c.hal_flash_write" title="Permalink to this definition">?</a></dt>
+<dd></dd></dl>
+
+<dl class="function">
+<dt id="c.hal_flash_erase_sector">
+<span class="target" id="group___h_a_l_flash_1gaea93a1a08bb8bd22eb54c2d5178a2a13"></span>int <code class="descname">hal_flash_erase_sector</code><span class="sig-paren">(</span>uint8_t<em>&nbsp;flash_id</em>, uint32_t<em>&nbsp;sector_address</em><span class="sig-paren">)</span><a class="headerlink" href="#c.hal_flash_erase_sector" title="Permalink to this definition">?</a></dt>
+<dd></dd></dl>
+
+<dl class="function">
+<dt id="c.hal_flash_erase">
+<span class="target" id="group___h_a_l_flash_1ga9f610de40a496b16602074e1d6459433"></span>int <code class="descname">hal_flash_erase</code><span class="sig-paren">(</span>uint8_t<em>&nbsp;flash_id</em>, uint32_t<em>&nbsp;address</em>, uint32_t<em>&nbsp;num_bytes</em><span class="sig-paren">)</span><a class="headerlink" href="#c.hal_flash_erase" title="Permalink to this definition">?</a></dt>
+<dd></dd></dl>
+
+<dl class="function">
+<dt id="c.hal_flash_align">
+<span class="target" id="group___h_a_l_flash_1ga9dda1efff3a52a664d9f76f35e25b60c"></span>uint8_t <code class="descname">hal_flash_align</code><span class="sig-paren">(</span>uint8_t<em>&nbsp;flash_id</em><span class="sig-paren">)</span><a class="headerlink" href="#c.hal_flash_align" title="Permalink to this definition">?</a></dt>
+<dd></dd></dl>
+
+<dl class="function">
+<dt id="c.hal_flash_init">
+<span class="target" id="group___h_a_l_flash_1gaa3aed2bc9e984945102ec5d9a92f4a10"></span>int <code class="descname">hal_flash_init</code><span class="sig-paren">(</span>void<span class="sig-paren">)</span><a class="headerlink" href="#c.hal_flash_init" title="Permalink to this definition">?</a></dt>
+<dd></dd></dl>
+
 </div>
 </div>
 
@@ -270,6 +325,15 @@ <h2>Examples<a class="headerlink" href="#examples" title="Permalink to this head
                    </div>
                   </div>
                   
+    <div class="rst-footer-buttons row" role="navigation" aria-label="footer navigation">
+      
+        <a href="../hal_watchdog/hal_watchdog.html" class="btn btn-neutral float-right" title="Watchdog" accesskey="n">Next: Watchdog <span class="fa fa-arrow-circle-right"></span></a>
+      
+      
+        <a href="../hal_i2c/hal_i2c.html" class="btn btn-neutral" title="I2C" accesskey="p"><span class="fa fa-arrow-circle-left"></span> Previous: I2C</a>
+      
+    </div>
+
                 </div>
               </div>
             </div>
diff --git a/develop/os/modules/hal/hal_gpio/hal_gpio.html b/develop/os/modules/hal/hal_gpio/hal_gpio.html
index 2f365278d..90a7f4c7e 100644
--- a/develop/os/modules/hal/hal_gpio/hal_gpio.html
+++ b/develop/os/modules/hal/hal_gpio/hal_gpio.html
@@ -10,7 +10,7 @@
     
 
     
-    <title>hal_gpio &mdash; Apache Mynewt 1.3.0 documentation</title>
+    <title>GPIO &mdash; Apache Mynewt 1.3.0 documentation</title>
     
 
     
@@ -40,7 +40,10 @@
           <link rel="index" title="Index"
                 href="../../../../genindex.html"/>
           <link rel="search" title="Search" href="../../../../search.html"/>
-      <link rel="top" title="Apache Mynewt 1.3.0 documentation" href="../../../../index.html"/> 
+      <link rel="top" title="Apache Mynewt 1.3.0 documentation" href="../../../../index.html"/>
+          <link rel="up" title="Hardware Abstraction Layer" href="../hal.html"/>
+          <link rel="next" title="UART" href="../hal_uart/hal_uart.html"/>
+          <link rel="prev" title="Timer" href="../hal_timer/hal_timer.html"/> 
 
     
     <script src="../../../../_static/js/modernizr.min.js"></script>
@@ -151,7 +154,11 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
   <div class="container">
     <a href="/documentation/">Docs</a> /
     
-    hal_gpio
+      <a href="../../../os_user_guide.html">OS User Guide</a> /
+    
+      <a href="../hal.html">Hardware Abstraction Layer</a> /
+    
+    GPIO
     
   <div class="sourcelink">
     <a href="https://github.com/apache/mynewt-core/edit/master/docs/os/modules/hal/hal_gpio/hal_gpio.rst" class="icon icon-github"
@@ -211,12 +218,29 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
       
         
         
-            <ul>
+            <ul class="current">
 <li class="toctree-l1"><a class="reference internal" href="../../../../index.html">Introduction</a></li>
 <li class="toctree-l1"><a class="reference internal" href="../../../../get_started/index.html">Setup &amp; Get Started</a></li>
 <li class="toctree-l1"><a class="reference internal" href="../../../../concepts.html">Concepts</a></li>
 <li class="toctree-l1"><a class="reference internal" href="../../../../tutorials/tutorials.html">Tutorials</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../../os_user_guide.html">OS User Guide</a></li>
+<li class="toctree-l1 current"><a class="reference internal" href="../../../os_user_guide.html">OS User Guide</a><ul class="current">
+<li class="toctree-l2"><a class="reference internal" href="../../../core_os/mynewt_os.html">Kernel</a></li>
+<li class="toctree-l2 current"><a class="reference internal" href="../hal.html">Hardware Abstraction</a><ul class="current">
+<li class="toctree-l3"><a class="reference internal" href="../hal_timer/hal_timer.html">Timer</a></li>
+<li class="toctree-l3 current"><a class="current reference internal" href="#">GPIO</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../hal_uart/hal_uart.html">UART</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../hal_spi/hal_spi.html">SPI</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../hal_i2c/hal_i2c.html">I2C</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../hal_flash/hal_flash.html">Flash</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../hal_watchdog/hal_watchdog.html">Watchdog</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../hal_bsp/hal_bsp.html">BSP</a></li>
+</ul>
+</li>
+<li class="toctree-l2"><a class="reference internal" href="../../../core_os/porting/port_os.html">Porting Guide</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../../sysinitconfig/sysinitconfig.html">System Configuration</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../../console/console.html">Console</a></li>
+</ul>
+</li>
 <li class="toctree-l1"><a class="reference internal" href="../../../../network/ble/ble_intro.html">BLE User Guide</a></li>
 <li class="toctree-l1"><a class="reference internal" href="../../../../newt/index.html">Newt Tool Guide</a></li>
 <li class="toctree-l1"><a class="reference internal" href="../../../../newtmgr/index.html">Newt Manager Guide</a></li>
@@ -248,8 +272,8 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
                   <div role="main" class="document" itemscope="itemscope" itemtype="http://schema.org/Article">
                    <div itemprop="articleBody">
                     
-  <div class="section" id="hal-gpio">
-<h1>hal_gpio<a class="headerlink" href="#hal-gpio" title="Permalink to this headline">?</a></h1>
+  <div class="section" id="gpio">
+<h1>GPIO<a class="headerlink" href="#gpio" title="Permalink to this headline">?</a></h1>
 <p>This is the hardware independent GPIO (General Purpose Input Output)
 Interface for Mynewt.</p>
 <div class="section" id="description">
@@ -291,21 +315,262 @@ <h2>Description<a class="headerlink" href="#description" title="Permalink to thi
 </pre></div>
 </div>
 </div>
-<div class="section" id="definition">
-<h2>Definition<a class="headerlink" href="#definition" title="Permalink to this headline">?</a></h2>
-<p><a class="reference external" href="https://github.com/apache/incubator-mynewt-core/blob/master/hw/hal/include/hal/hal_gpio.h">hal_gpio.h</a></p>
-</div>
-<div class="section" id="examples">
-<h2>Examples<a class="headerlink" href="#examples" title="Permalink to this headline">?</a></h2>
-<div class="section" id="blinky">
-<h3>Blinky<a class="headerlink" href="#blinky" title="Permalink to this headline">?</a></h3>
-<p>Blinky uses the hal_gpio to blink the system LED. The blinky source
-code is available in the <a class="reference external" href="https://github.com/apache/incubator-mynewt-blinky/blob/master/apps/blinky/src/main.c">blinky
-repo</a>.
-Examine how <code class="docutils literal notranslate"><span class="pre">blinky_task_handler</span></code> initializes and toggles the GPIO to
-control the LED.</p>
-<hr class="docutils" />
-</div>
+<div class="section" id="api">
+<h2>API<a class="headerlink" href="#api" title="Permalink to this headline">?</a></h2>
+<dl class="enum">
+<dt id="c.HALGpio::hal_gpio_mode_e">
+<span class="target" id="group___h_a_l_gpio_1ga05d33c14218c9a540b36d8368cfccc4e"></span><em class="property">enum </em><code class="descclassname">HALGpio::</code><code class="descname">hal_gpio_mode_e</code><a class="headerlink" href="#c.HALGpio::hal_gpio_mode_e" title="Permalink to this definition">?</a></dt>
+<dd><p>The ?mode? of the gpio. </p>
+<p>The gpio is either an input, output, or it is ?not connected? (the pin specified is not functioning as a gpio) </p>
+<p><em>Values:</em></p>
+<dl class="enumvalue">
+<dt id="c.HALGpio::HAL_GPIO_MODE_NC">
+<span class="target" id="group___h_a_l_gpio_1gga05d33c14218c9a540b36d8368cfccc4ea7a0bc7ac854ea5d1d5cdd5afdb574943"></span><code class="descname">HAL_GPIO_MODE_NC</code> = -1<a class="headerlink" href="#c.HALGpio::HAL_GPIO_MODE_NC" title="Permalink to this definition">?</a></dt>
+<dd><p>Not connected. </p>
+</dd></dl>
+
+<dl class="enumvalue">
+<dt id="c.HALGpio::HAL_GPIO_MODE_IN">
+<span class="target" id="group___h_a_l_gpio_1gga05d33c14218c9a540b36d8368cfccc4ea1cdd3f47a122d021908af28514135b0d"></span><code class="descname">HAL_GPIO_MODE_IN</code> = 0<a class="headerlink" href="#c.HALGpio::HAL_GPIO_MODE_IN" title="Permalink to this definition">?</a></dt>
+<dd><p>Input. </p>
+</dd></dl>
+
+<dl class="enumvalue">
+<dt id="c.HALGpio::HAL_GPIO_MODE_OUT">
+<span class="target" id="group___h_a_l_gpio_1gga05d33c14218c9a540b36d8368cfccc4ea4c7f8a4977ea851187d600bc390e9e90"></span><code class="descname">HAL_GPIO_MODE_OUT</code> = 1<a class="headerlink" href="#c.HALGpio::HAL_GPIO_MODE_OUT" title="Permalink to this definition">?</a></dt>
+<dd><p>Output. </p>
+</dd></dl>
+
+</dd></dl>
+
+<dl class="enum">
+<dt id="c.HALGpio::hal_gpio_pull">
+<span class="target" id="group___h_a_l_gpio_1ga7d6c41232ae1659321fdb8d83ecb0602"></span><em class="property">enum </em><code class="descclassname">HALGpio::</code><code class="descname">hal_gpio_pull</code><a class="headerlink" href="#c.HALGpio::hal_gpio_pull" title="Permalink to this definition">?</a></dt>
+<dd><p><em>Values:</em></p>
+<dl class="enumvalue">
+<dt id="c.HALGpio::HAL_GPIO_PULL_NONE">
+<span class="target" id="group___h_a_l_gpio_1gga7d6c41232ae1659321fdb8d83ecb0602a1bf6748c4e1ad5b4ef9257f9146be798"></span><code class="descname">HAL_GPIO_PULL_NONE</code> = 0<a class="headerlink" href="#c.HALGpio::HAL_GPIO_PULL_NONE" title="Permalink to this definition">?</a></dt>
+<dd><p>Pull-up/down not enabled. </p>
+</dd></dl>
+
+<dl class="enumvalue">
+<dt id="c.HALGpio::HAL_GPIO_PULL_UP">
+<span class="target" id="group___h_a_l_gpio_1gga7d6c41232ae1659321fdb8d83ecb0602a877c8cc65df5733424ba21e788890d08"></span><code class="descname">HAL_GPIO_PULL_UP</code> = 1<a class="headerlink" href="#c.HALGpio::HAL_GPIO_PULL_UP" title="Permalink to this definition">?</a></dt>
+<dd><p>Pull-up enabled. </p>
+</dd></dl>
+
+<dl class="enumvalue">
+<dt id="c.HALGpio::HAL_GPIO_PULL_DOWN">
+<span class="target" id="group___h_a_l_gpio_1gga7d6c41232ae1659321fdb8d83ecb0602a386567f3dec876c7b850a2a1359535c2"></span><code class="descname">HAL_GPIO_PULL_DOWN</code> = 2<a class="headerlink" href="#c.HALGpio::HAL_GPIO_PULL_DOWN" title="Permalink to this definition">?</a></dt>
+<dd><p>Pull-down enabled. </p>
+</dd></dl>
+
+</dd></dl>
+
+<dl class="enum">
+<dt id="c.HALGpio::hal_gpio_irq_trigger">
+<span class="target" id="group___h_a_l_gpio_1ga746d10c5b6de39dba3ba87ccf699c790"></span><em class="property">enum </em><code class="descclassname">HALGpio::</code><code class="descname">hal_gpio_irq_trigger</code><a class="headerlink" href="#c.HALGpio::hal_gpio_irq_trigger" title="Permalink to this definition">?</a></dt>
+<dd><p><em>Values:</em></p>
+<dl class="enumvalue">
+<dt id="c.HALGpio::HAL_GPIO_TRIG_NONE">
+<span class="target" id="group___h_a_l_gpio_1gga746d10c5b6de39dba3ba87ccf699c790ab293dbc504ffe6acfc94c10315934631"></span><code class="descname">HAL_GPIO_TRIG_NONE</code> = 0<a class="headerlink" href="#c.HALGpio::HAL_GPIO_TRIG_NONE" title="Permalink to this definition">?</a></dt>
+<dd></dd></dl>
+
+<dl class="enumvalue">
+<dt id="c.HALGpio::HAL_GPIO_TRIG_RISING">
+<span class="target" id="group___h_a_l_gpio_1gga746d10c5b6de39dba3ba87ccf699c790a619f7fff6a04445a9bfee1942100dd98"></span><code class="descname">HAL_GPIO_TRIG_RISING</code> = 1<a class="headerlink" href="#c.HALGpio::HAL_GPIO_TRIG_RISING" title="Permalink to this definition">?</a></dt>
+<dd><p>IRQ occurs on rising edge. </p>
+</dd></dl>
+
+<dl class="enumvalue">
+<dt id="c.HALGpio::HAL_GPIO_TRIG_FALLING">
+<span class="target" id="group___h_a_l_gpio_1gga746d10c5b6de39dba3ba87ccf699c790a3418cf236fda37588bbcd7b230ca3f75"></span><code class="descname">HAL_GPIO_TRIG_FALLING</code> = 2<a class="headerlink" href="#c.HALGpio::HAL_GPIO_TRIG_FALLING" title="Permalink to this definition">?</a></dt>
+<dd><p>IRQ occurs on falling edge. </p>
+</dd></dl>
+
+<dl class="enumvalue">
+<dt id="c.HALGpio::HAL_GPIO_TRIG_BOTH">
+<span class="target" id="group___h_a_l_gpio_1gga746d10c5b6de39dba3ba87ccf699c790aa5113a87c39a27cc38924cd2f3f0fb13"></span><code class="descname">HAL_GPIO_TRIG_BOTH</code> = 3<a class="headerlink" href="#c.HALGpio::HAL_GPIO_TRIG_BOTH" title="Permalink to this definition">?</a></dt>
+<dd><p>IRQ occurs on either edge. </p>
+</dd></dl>
+
+<dl class="enumvalue">
+<dt id="c.HALGpio::HAL_GPIO_TRIG_LOW">
+<span class="target" id="group___h_a_l_gpio_1gga746d10c5b6de39dba3ba87ccf699c790a0868ce8b2ed4b9d0225d7a9cf7327105"></span><code class="descname">HAL_GPIO_TRIG_LOW</code> = 4<a class="headerlink" href="#c.HALGpio::HAL_GPIO_TRIG_LOW" title="Permalink to this definition">?</a></dt>
+<dd><p>IRQ occurs when line is low. </p>
+</dd></dl>
+
+<dl class="enumvalue">
+<dt id="c.HALGpio::HAL_GPIO_TRIG_HIGH">
+<span class="target" id="group___h_a_l_gpio_1gga746d10c5b6de39dba3ba87ccf699c790a616f9424f3760152478d96720f78cb82"></span><code class="descname">HAL_GPIO_TRIG_HIGH</code> = 5<a class="headerlink" href="#c.HALGpio::HAL_GPIO_TRIG_HIGH" title="Permalink to this definition">?</a></dt>
+<dd><p>IRQ occurs when line is high. </p>
+</dd></dl>
+
+</dd></dl>
+
+<dl class="typedef">
+<dt id="c.hal_gpio_mode_t">
+<span class="target" id="group___h_a_l_gpio_1ga5040ea4ce60b1fa001963143c56123d4"></span><em class="property">typedef </em>enum hal_gpio_mode_e <code class="descname">hal_gpio_mode_t</code><a class="headerlink" href="#c.hal_gpio_mode_t" title="Permalink to this definition">?</a></dt>
+<dd></dd></dl>
+
+<dl class="typedef">
+<dt id="c.hal_gpio_pull_t">
+<span class="target" id="group___h_a_l_gpio_1gaa96291053d9fd1f8890ea1df9de686a3"></span><em class="property">typedef </em>enum hal_gpio_pull <code class="descname">hal_gpio_pull_t</code><a class="headerlink" href="#c.hal_gpio_pull_t" title="Permalink to this definition">?</a></dt>
+<dd></dd></dl>
+
+<dl class="typedef">
+<dt id="c.hal_gpio_irq_trig_t">
+<span class="target" id="group___h_a_l_gpio_1ga49380279d2a339d21e9764e705ff6748"></span><em class="property">typedef </em>enum hal_gpio_irq_trigger <code class="descname">hal_gpio_irq_trig_t</code><a class="headerlink" href="#c.hal_gpio_irq_trig_t" title="Permalink to this definition">?</a></dt>
+<dd></dd></dl>
+
+<dl class="typedef">
+<dt id="c.hal_gpio_irq_handler_t">
+<span class="target" id="group___h_a_l_gpio_1ga4e27cbc81cfeb6d4827f5789bffc1bf2"></span><em class="property">typedef </em>void<code class="descname">(* hal_gpio_irq_handler_t)</code><span class="sig-paren">(</span>void<em>&nbsp;*arg</em><span class="sig-paren">)</span><a class="headerlink" href="#c.hal_gpio_irq_handler_t" title="Permalink to this definition">?</a></dt>
+<dd></dd></dl>
+
+<dl class="function">
+<dt id="c.hal_gpio_init_in">
+<span class="target" id="group___h_a_l_gpio_1ga6f871cb613f87d328f9098484d34982e"></span>int <code class="descname">hal_gpio_init_in</code><span class="sig-paren">(</span>int<em>&nbsp;pin</em>, <a class="reference internal" href="#c.hal_gpio_pull_t" title="hal_gpio_pull_t">hal_gpio_pull_t</a><em>&nbsp;pull</em><span class="sig-paren">)</span><a class="headerlink" href="#c.hal_gpio_init_in" title="Permalink to this definition">?</a></dt>
+<dd><p>Initializes the specified pin as an input. </p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>int 0: no error; -1 otherwise. </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">pin</span></code>: Pin number to set as input </li>
+<li><code class="docutils literal notranslate"><span class="pre">pull</span></code>: pull type</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.hal_gpio_init_out">
+<span class="target" id="group___h_a_l_gpio_1ga7594e2079435ac6f3a6950bcd99b33c7"></span>int <code class="descname">hal_gpio_init_out</code><span class="sig-paren">(</span>int<em>&nbsp;pin</em>, int<em>&nbsp;val</em><span class="sig-paren">)</span><a class="headerlink" href="#c.hal_gpio_init_out" title="Permalink to this definition">?</a></dt>
+<dd><p>Initialize the specified pin as an output, setting the pin to the specified value. </p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>int 0: no error; -1 otherwise. </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">pin</span></code>: Pin number to set as output </li>
+<li><code class="docutils literal notranslate"><span class="pre">val</span></code>: Value to set pin</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.hal_gpio_write">
+<span class="target" id="group___h_a_l_gpio_1gaf84a65839b9b04225131714c9bd16049"></span>void <code class="descname">hal_gpio_write</code><span class="sig-paren">(</span>int<em>&nbsp;pin</em>, int<em>&nbsp;val</em><span class="sig-paren">)</span><a class="headerlink" href="#c.hal_gpio_write" title="Permalink to this definition">?</a></dt>
+<dd><p>Write a value (either high or low) to the specified pin. </p>
+<p><dl class="docutils">
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">pin</span></code>: Pin to set </li>
+<li><code class="docutils literal notranslate"><span class="pre">val</span></code>: Value to set pin (0:low 1:high) </li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.hal_gpio_read">
+<span class="target" id="group___h_a_l_gpio_1ga4036d26c86d52e1f2e1e8d058126dae9"></span>int <code class="descname">hal_gpio_read</code><span class="sig-paren">(</span>int<em>&nbsp;pin</em><span class="sig-paren">)</span><a class="headerlink" href="#c.hal_gpio_read" title="Permalink to this definition">?</a></dt>
+<dd><p>Reads the specified pin. </p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>int 0: low, 1: high </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">pin</span></code>: Pin number to read</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.hal_gpio_toggle">
+<span class="target" id="group___h_a_l_gpio_1ga41cb6827b643d7b54da660987b280a85"></span>int <code class="descname">hal_gpio_toggle</code><span class="sig-paren">(</span>int<em>&nbsp;pin</em><span class="sig-paren">)</span><a class="headerlink" href="#c.hal_gpio_toggle" title="Permalink to this definition">?</a></dt>
+<dd><p>Toggles the specified pin. </p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>current gpio state int 0: low, 1: high </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">pin</span></code>: Pin number to toggle</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.hal_gpio_irq_init">
+<span class="target" id="group___h_a_l_gpio_1gaf2d98059c05b0b3867699f83675205fd"></span>int <code class="descname">hal_gpio_irq_init</code><span class="sig-paren">(</span>int<em>&nbsp;pin</em>, <a class="reference internal" href="#c.hal_gpio_irq_handler_t" title="hal_gpio_irq_handler_t">hal_gpio_irq_handler_t</a><em>&nbsp;handler</em>, void *<em>&nbsp;arg</em>, <a class="reference internal" href="#c.hal_gpio_irq_trig_t" title="hal_gpio_irq_trig_t">hal_gpio_irq_trig_t</a><em>&nbsp;trig</em>, <a class="reference internal" href="#c.hal_gpio_pull_t" title="hal_gpio_pull_t">hal_gpio_pull_t</a><em>&nbsp;pull</em><span class="sig-paren">)</span><a class="headerlink" href="#c.hal_gpio_irq_init" title="Permalink to this definition">?</a></dt>
+<dd><p>Initialize a given pin to trigger a GPIO IRQ callback. </p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>0 on success, non-zero error code on failure. </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">pin</span></code>: The pin to trigger GPIO interrupt on </li>
+<li><code class="docutils literal notranslate"><span class="pre">handler</span></code>: The handler function to call </li>
+<li><code class="docutils literal notranslate"><span class="pre">arg</span></code>: The argument to provide to the IRQ handler </li>
+<li><code class="docutils literal notranslate"><span class="pre">trig</span></code>: The trigger mode (e.g. rising, falling) </li>
+<li><code class="docutils literal notranslate"><span class="pre">pull</span></code>: The mode of the pin (e.g. pullup, pulldown)</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.hal_gpio_irq_release">
+<span class="target" id="group___h_a_l_gpio_1ga233f5726dc049c11c02a7ea6e17bbe5c"></span>void <code class="descname">hal_gpio_irq_release</code><span class="sig-paren">(</span>int<em>&nbsp;pin</em><span class="sig-paren">)</span><a class="headerlink" href="#c.hal_gpio_irq_release" title="Permalink to this definition">?</a></dt>
+<dd><p>Release a pin from being configured to trigger IRQ on state change. </p>
+<p><dl class="docutils">
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">pin</span></code>: The pin to release </li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.hal_gpio_irq_enable">
+<span class="target" id="group___h_a_l_gpio_1gaf5a12227e02c35222b5c00b84bdf11a0"></span>void <code class="descname">hal_gpio_irq_enable</code><span class="sig-paren">(</span>int<em>&nbsp;pin</em><span class="sig-paren">)</span><a class="headerlink" href="#c.hal_gpio_irq_enable" title="Permalink to this definition">?</a></dt>
+<dd><p>Enable IRQs on the passed pin. </p>
+<p><dl class="docutils">
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">pin</span></code>: The pin to enable IRQs on </li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.hal_gpio_irq_disable">
+<span class="target" id="group___h_a_l_gpio_1ga7762336b37c8f239085952ece2eb2941"></span>void <code class="descname">hal_gpio_irq_disable</code><span class="sig-paren">(</span>int<em>&nbsp;pin</em><span class="sig-paren">)</span><a class="headerlink" href="#c.hal_gpio_irq_disable" title="Permalink to this definition">?</a></dt>
+<dd><p>Disable IRQs on the passed pin. </p>
+<p><dl class="docutils">
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">pin</span></code>: The pin to disable IRQs on </li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
 </div>
 </div>
 
@@ -313,6 +578,15 @@ <h3>Blinky<a class="headerlink" href="#blinky" title="Permalink to this headline
                    </div>
                   </div>
                   
+    <div class="rst-footer-buttons row" role="navigation" aria-label="footer navigation">
+      
+        <a href="../hal_uart/hal_uart.html" class="btn btn-neutral float-right" title="UART" accesskey="n">Next: UART <span class="fa fa-arrow-circle-right"></span></a>
+      
+      
+        <a href="../hal_timer/hal_timer.html" class="btn btn-neutral" title="Timer" accesskey="p"><span class="fa fa-arrow-circle-left"></span> Previous: Timer</a>
+      
+    </div>
+
                 </div>
               </div>
             </div>
diff --git a/develop/os/modules/hal/hal_i2c/hal_i2c.html b/develop/os/modules/hal/hal_i2c/hal_i2c.html
index 047dac458..20667eaad 100644
--- a/develop/os/modules/hal/hal_i2c/hal_i2c.html
+++ b/develop/os/modules/hal/hal_i2c/hal_i2c.html
@@ -10,7 +10,7 @@
     
 
     
-    <title>hal_i2c &mdash; Apache Mynewt 1.3.0 documentation</title>
+    <title>I2C &mdash; Apache Mynewt 1.3.0 documentation</title>
     
 
     
@@ -40,7 +40,10 @@
           <link rel="index" title="Index"
                 href="../../../../genindex.html"/>
           <link rel="search" title="Search" href="../../../../search.html"/>
-      <link rel="top" title="Apache Mynewt 1.3.0 documentation" href="../../../../index.html"/> 
+      <link rel="top" title="Apache Mynewt 1.3.0 documentation" href="../../../../index.html"/>
+          <link rel="up" title="Hardware Abstraction Layer" href="../hal.html"/>
+          <link rel="next" title="Flash" href="../hal_flash/hal_flash.html"/>
+          <link rel="prev" title="SPI" href="../hal_spi/hal_spi.html"/> 
 
     
     <script src="../../../../_static/js/modernizr.min.js"></script>
@@ -151,7 +154,11 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
   <div class="container">
     <a href="/documentation/">Docs</a> /
     
-    hal_i2c
+      <a href="../../../os_user_guide.html">OS User Guide</a> /
+    
+      <a href="../hal.html">Hardware Abstraction Layer</a> /
+    
+    I2C
     
   <div class="sourcelink">
     <a href="https://github.com/apache/mynewt-core/edit/master/docs/os/modules/hal/hal_i2c/hal_i2c.rst" class="icon icon-github"
@@ -211,12 +218,29 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
       
         
         
-            <ul>
+            <ul class="current">
 <li class="toctree-l1"><a class="reference internal" href="../../../../index.html">Introduction</a></li>
 <li class="toctree-l1"><a class="reference internal" href="../../../../get_started/index.html">Setup &amp; Get Started</a></li>
 <li class="toctree-l1"><a class="reference internal" href="../../../../concepts.html">Concepts</a></li>
 <li class="toctree-l1"><a class="reference internal" href="../../../../tutorials/tutorials.html">Tutorials</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../../os_user_guide.html">OS User Guide</a></li>
+<li class="toctree-l1 current"><a class="reference internal" href="../../../os_user_guide.html">OS User Guide</a><ul class="current">
+<li class="toctree-l2"><a class="reference internal" href="../../../core_os/mynewt_os.html">Kernel</a></li>
+<li class="toctree-l2 current"><a class="reference internal" href="../hal.html">Hardware Abstraction</a><ul class="current">
+<li class="toctree-l3"><a class="reference internal" href="../hal_timer/hal_timer.html">Timer</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../hal_gpio/hal_gpio.html">GPIO</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../hal_uart/hal_uart.html">UART</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../hal_spi/hal_spi.html">SPI</a></li>
+<li class="toctree-l3 current"><a class="current reference internal" href="#">I2C</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../hal_flash/hal_flash.html">Flash</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../hal_watchdog/hal_watchdog.html">Watchdog</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../hal_bsp/hal_bsp.html">BSP</a></li>
+</ul>
+</li>
+<li class="toctree-l2"><a class="reference internal" href="../../../core_os/porting/port_os.html">Porting Guide</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../../sysinitconfig/sysinitconfig.html">System Configuration</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../../console/console.html">Console</a></li>
+</ul>
+</li>
 <li class="toctree-l1"><a class="reference internal" href="../../../../network/ble/ble_intro.html">BLE User Guide</a></li>
 <li class="toctree-l1"><a class="reference internal" href="../../../../newt/index.html">Newt Tool Guide</a></li>
 <li class="toctree-l1"><a class="reference internal" href="../../../../newtmgr/index.html">Newt Manager Guide</a></li>
@@ -248,8 +272,8 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
                   <div role="main" class="document" itemscope="itemscope" itemtype="http://schema.org/Article">
                    <div itemprop="articleBody">
                     
-  <div class="section" id="hal-i2c">
-<h1>hal_i2c<a class="headerlink" href="#hal-i2c" title="Permalink to this headline">?</a></h1>
+  <div class="section" id="i2c">
+<h1>I2C<a class="headerlink" href="#i2c" title="Permalink to this headline">?</a></h1>
 <p>The hardware independent interface to I2C Devices.</p>
 <div class="section" id="description">
 <h2>Description<a class="headerlink" href="#description" title="Permalink to this headline">?</a></h2>
@@ -261,10 +285,6 @@ <h2>Description<a class="headerlink" href="#description" title="Permalink to thi
 <p>For a detailed description of I2C, see the <a class="reference external" href="https://en.wikipedia.org/wiki/I?C">I?C wikipedia
 page</a></p>
 </div>
-<div class="section" id="definition">
-<h2>Definition<a class="headerlink" href="#definition" title="Permalink to this headline">?</a></h2>
-<p><a class="reference external" href="https://github.com/apache/incubator-mynewt-core/blob/master/hw/hal/include/hal/hal_i2c.h">hal_i2c.h</a></p>
-</div>
 <div class="section" id="hal-i2c-theory-of-operation">
 <h2>HAL_I2C Theory Of Operation<a class="headerlink" href="#hal-i2c-theory-of-operation" title="Permalink to this headline">?</a></h2>
 <p>An I?C transaction typically involves acquiring the bus, sending and/or
@@ -359,6 +379,114 @@ <h2>HAL_I2C Data<a class="headerlink" href="#hal-i2c-data" title="Permalink to t
 <code class="docutils literal notranslate"><span class="pre">0b1000110</span></code>, which is hex 0x46 or decimal 70. The I?C drive would add
 the R/W bit and transmit it as hex 0x8C (binary 10001100) or 0x8D
 (binary 10001101) depending whether it was a read or write command.</p>
+</div>
+<div class="section" id="api">
+<h2>API<a class="headerlink" href="#api" title="Permalink to this headline">?</a></h2>
+<dl class="function">
+<dt id="c.hal_i2c_init">
+<span class="target" id="group___h_a_l_i2c_1ga168e312fdccc376294a2f537a25e06d8"></span>int <code class="descname">hal_i2c_init</code><span class="sig-paren">(</span>uint8_t<em>&nbsp;i2c_num</em>, void *<em>&nbsp;cfg</em><span class="sig-paren">)</span><a class="headerlink" href="#c.hal_i2c_init" title="Permalink to this definition">?</a></dt>
+<dd><p>Initialize a new i2c device with the I2C number. </p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>0 on success, and non-zero error code on failure </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">i2c_num</span></code>: The number of the I2C device being initialized </li>
+<li><code class="docutils literal notranslate"><span class="pre">cfg</span></code>: The hardware specific configuration structure to configure the I2C with. This includes things like pin configuration.</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.hal_i2c_master_write">
+<span class="target" id="group___h_a_l_i2c_1ga647137bb25fef80383b3c58691c6e173"></span>int <code class="descname">hal_i2c_master_write</code><span class="sig-paren">(</span>uint8_t<em>&nbsp;i2c_num</em>, struct  hal_i2c_master_data  *<em>&nbsp;pdata</em>, uint32_t<em>&nbsp;timeout</em>, uint8_t<em>&nbsp;last_op</em><span class="sig-paren">)</span><a class="headerlink" href="#c.hal_i2c_master_write" title="Permalink to this definition">?</a></dt>
+<dd><p>Sends a start condition and writes &lt;len&gt; bytes of data on the i2c bus. </p>
+<p>This API does NOT issue a stop condition unless <code class="docutils literal notranslate"><span class="pre">last_op</span></code> is set to <code class="docutils literal notranslate"><span class="pre">1</span></code>. You must stop the bus after successful or unsuccessful write attempts. This API is blocking until an error or NaK occurs. Timeout is platform dependent.</p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>0 on success, and non-zero error code on failure </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">i2c_num</span></code>: The number of the I2C device being written to </li>
+<li><code class="docutils literal notranslate"><span class="pre">pdata</span></code>: The data to write to the I2C bus </li>
+<li><code class="docutils literal notranslate"><span class="pre">timeout</span></code>: How long to wait for transaction to complete in ticks </li>
+<li><code class="docutils literal notranslate"><span class="pre">last_op</span></code>: Master should send a STOP at the end to signify end of transaction.</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.hal_i2c_master_read">
+<span class="target" id="group___h_a_l_i2c_1gab19941d920a74650ebd9f9790f48fa62"></span>int <code class="descname">hal_i2c_master_read</code><span class="sig-paren">(</span>uint8_t<em>&nbsp;i2c_num</em>, struct  hal_i2c_master_data  *<em>&nbsp;pdata</em>, uint32_t<em>&nbsp;timeout</em>, uint8_t<em>&nbsp;last_op</em><span class="sig-paren">)</span><a class="headerlink" href="#c.hal_i2c_master_read" title="Permalink to this definition">?</a></dt>
+<dd><p>Sends a start condition and reads &lt;len&gt; bytes of data on the i2c bus. </p>
+<p>This API does NOT issue a stop condition unless <code class="docutils literal notranslate"><span class="pre">last_op</span></code> is set to <code class="docutils literal notranslate"><span class="pre">1</span></code>. You must stop the bus after successful or unsuccessful write attempts. This API is blocking until an error or NaK occurs. Timeout is platform dependent.</p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>0 on success, and non-zero error code on failure </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">i2c_num</span></code>: The number of the I2C device being written to </li>
+<li><code class="docutils literal notranslate"><span class="pre">pdata</span></code>: The location to place read data </li>
+<li><code class="docutils literal notranslate"><span class="pre">timeout</span></code>: How long to wait for transaction to complete in ticks </li>
+<li><code class="docutils literal notranslate"><span class="pre">last_op</span></code>: Master should send a STOP at the end to signify end of transaction.</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.hal_i2c_master_probe">
+<span class="target" id="group___h_a_l_i2c_1ga53de5cf24903b7984a226276dd2a117e"></span>int <code class="descname">hal_i2c_master_probe</code><span class="sig-paren">(</span>uint8_t<em>&nbsp;i2c_num</em>, uint8_t<em>&nbsp;address</em>, uint32_t<em>&nbsp;timeout</em><span class="sig-paren">)</span><a class="headerlink" href="#c.hal_i2c_master_probe" title="Permalink to this definition">?</a></dt>
+<dd><p>Probes the i2c bus for a device with this address. </p>
+<p>THIS API issues a start condition, probes the address using a read command and issues a stop condition.</p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>0 on success, non-zero error code on failure </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">i2c_num</span></code>: The number of the I2C to probe </li>
+<li><code class="docutils literal notranslate"><span class="pre">address</span></code>: The address to probe for </li>
+<li><code class="docutils literal notranslate"><span class="pre">timeout</span></code>: How long to wait for transaction to complete in ticks</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="class">
+<dt id="_CPPv319hal_i2c_master_data">
+<span id="_CPPv219hal_i2c_master_data"></span><span id="hal_i2c_master_data"></span><span class="target" id="structhal__i2c__master__data"></span><em class="property">struct </em><code class="descname">hal_i2c_master_data</code><a class="headerlink" href="#_CPPv319hal_i2c_master_data" title="Permalink to this definition">?</a><br /></dt>
+<dd><em>#include &lt;hal_i2c.h&gt;</em><p>This is the API for an i2c bus. </p>
+<p>Currently, this is a master API allowing the mynewt device to function as an I2C master.</p>
+<p>A slave API is pending for future release</p>
+<p>Typical usage of this API is as follows:</p>
+<p>Initialize an i2c device with: :c:func:<code class="docutils literal notranslate"><a class="reference internal" href="#group___h_a_l_i2c_1ga168e312fdccc376294a2f537a25e06d8"><span class="std std-ref"><span class="pre">hal_i2c_init()</span></span></a></code></p>
+<p>When you wish to perform an i2c transaction, you call one or both of: :c:func:<code class="docutils literal notranslate"><a class="reference internal" href="#group___h_a_l_i2c_1ga647137bb25fef80383b3c58691c6e173"><span class="std std-ref"><span class="pre">hal_i2c_master_write()</span></span></a></code>; :c:func:<code class="docutils literal notranslate"><a class="reference internal" href="#group___h_a_l_i2c_1gab19941d920a74650ebd9f9790f48fa62"><span class="std std-ref"><span class="pre">hal_i2c_master_read()</span></span></a></code>;</p>
+<p>These functions will issue a START condition, followed by the device?s 7-bit I2C address, and then send or receive the payload based on the data provided. This will cause a repeated start on the bus, which is valid in I2C specification, and the decision to use repeated starts was made to simplify the I2C HAL. To set the STOP condition at an appropriate moment, you set the <code class="docutils literal notranslate"><span class="pre">last_op</span></code> field to a <code class="docutils literal notranslate"><span class="pre">1</span></code> in either function.</p>
+<p>For example, in an I2C memory access you might write a register address and then read data back via: :c:func:<code class="docutils literal notranslate"><span class="pre">hal_i2c_write()</span></code>;  write to a specific register on the device :c:func:<code class="docutils literal notranslate"><span class="pre">hal_i2c_read()</span></code>;  read back data, setting ?last_op? to ?1? When sending a packet, use this structure to pass the arguments. </p>
+<div class="breathe-sectiondef docutils container">
+<p class="breathe-sectiondef-title rubric">Public Members</p>
+<dl class="variable">
+<dt id="c.hal_i2c_master_data::address">
+<span class="target" id="structhal__i2c__master__data_1a4d8e02692037b21eaf2a4528b24c03ca"></span>uint8_t <code class="descname">address</code><a class="headerlink" href="#c.hal_i2c_master_data::address" title="Permalink to this definition">?</a></dt>
+<dd><p>Destination address An I2C address has 7 bits. </p>
+<p>In the protocol these 7 bits are combined with a 1 bit R/W bit to specify read or write operation in an 8-bit address field sent to the remote device. This API accepts the 7-bit address as its argument in the 7 LSBs of the address field above. For example if I2C was writing a 0x81 in its protocol, you would pass only the top 7-bits to this function as 0x40Number of buffer bytes to transmit or receive </p>
+</dd></dl>
+
+<dl class="variable">
+<dt id="c.hal_i2c_master_data::buffer">
+<span class="target" id="structhal__i2c__master__data_1ad26ebbf5cce03225f2275d83c5de70b1"></span>uint8_t* <code class="descname">buffer</code><a class="headerlink" href="#c.hal_i2c_master_data::buffer" title="Permalink to this definition">?</a></dt>
+<dd><p>Buffer space to hold the transmit or receive. </p>
+</dd></dl>
+
+</div>
+</dd></dl>
+
 </div>
 </div>
 
@@ -366,6 +494,15 @@ <h2>HAL_I2C Data<a class="headerlink" href="#hal-i2c-data" title="Permalink to t
                    </div>
                   </div>
                   
+    <div class="rst-footer-buttons row" role="navigation" aria-label="footer navigation">
+      
+        <a href="../hal_flash/hal_flash.html" class="btn btn-neutral float-right" title="Flash" accesskey="n">Next: Flash <span class="fa fa-arrow-circle-right"></span></a>
+      
+      
+        <a href="../hal_spi/hal_spi.html" class="btn btn-neutral" title="SPI" accesskey="p"><span class="fa fa-arrow-circle-left"></span> Previous: SPI</a>
+      
+    </div>
+
                 </div>
               </div>
             </div>
diff --git a/develop/os/modules/hal/hal_os_tick/hal_os_tick.html b/develop/os/modules/hal/hal_os_tick/hal_os_tick.html
index 06c6b2338..1c3a92569 100644
--- a/develop/os/modules/hal/hal_os_tick/hal_os_tick.html
+++ b/develop/os/modules/hal/hal_os_tick/hal_os_tick.html
@@ -10,7 +10,7 @@
     
 
     
-    <title>hal_os_tick &mdash; Apache Mynewt 1.3.0 documentation</title>
+    <title>OS Tick &mdash; Apache Mynewt 1.3.0 documentation</title>
     
 
     
@@ -151,7 +151,7 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
   <div class="container">
     <a href="/documentation/">Docs</a> /
     
-    hal_os_tick
+    OS Tick
     
   <div class="sourcelink">
     <a href="https://github.com/apache/mynewt-core/edit/master/docs/os/modules/hal/hal_os_tick/hal_os_tick.rst" class="icon icon-github"
@@ -248,8 +248,8 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
                   <div role="main" class="document" itemscope="itemscope" itemtype="http://schema.org/Article">
                    <div itemprop="articleBody">
                     
-  <div class="section" id="hal-os-tick">
-<h1>hal_os_tick<a class="headerlink" href="#hal-os-tick" title="Permalink to this headline">?</a></h1>
+  <div class="section" id="os-tick">
+<h1>OS Tick<a class="headerlink" href="#os-tick" title="Permalink to this headline">?</a></h1>
 <p>The hardware independent interface to set up interrupt timers or halt
 CPU in terms of OS ticks.</p>
 <div class="section" id="description">
@@ -267,16 +267,38 @@ <h2>Description<a class="headerlink" href="#description" title="Permalink to thi
 <p>The function implementations are in the mcu-specific directories such as
 <code class="docutils literal notranslate"><span class="pre">hw/mcu/nordic/nrf51xxx/src/hal_os_tick.c</span></code>.</p>
 </div>
-<div class="section" id="definition">
-<h2>Definition<a class="headerlink" href="#definition" title="Permalink to this headline">?</a></h2>
-<p><a class="reference external" href="https://github.com/apache/incubator-mynewt-core/blob/master/hw/hal/include/hal/hal_os_tick.h">hal_os_tick.h</a></p>
-</div>
-<div class="section" id="examples">
-<h2>Examples<a class="headerlink" href="#examples" title="Permalink to this headline">?</a></h2>
-<p>An example of the API being used by the OS kernel for the Cortex M0
-architecture to initialize and start the system clock timer can be seen
-in
-<a class="reference external" href="https://github.com/apache/incubator-mynewt-core/blob/master/kernel/os/src/arch/cortex_m0/os_arch_arm.c">kernel/os/src/arch/cortex_m0/os_arch_arm.c</a>.</p>
+<div class="section" id="api">
+<h2>API<a class="headerlink" href="#api" title="Permalink to this headline">?</a></h2>
+<dl class="function">
+<dt id="c.os_tick_init">
+<span class="target" id="group___h_a_l_os_tick_1ga2f079bb2eceefe6157702c7e0330fa92"></span>void <code class="descname">os_tick_init</code><span class="sig-paren">(</span>uint32_t<em>&nbsp;os_ticks_per_sec</em>, int<em>&nbsp;prio</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_tick_init" title="Permalink to this definition">?</a></dt>
+<dd><p>Set up the periodic timer to interrupt at a frequency of ?os_ticks_per_sec?. </p>
+<p>?prio? is the cpu-specific priority of the periodic timer interrupt.</p>
+<p><dl class="docutils">
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">os_ticks_per_sec</span></code>: Frequency of the OS tick timer </li>
+<li><code class="docutils literal notranslate"><span class="pre">prio</span></code>: Priority of the OS tick timer </li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.os_tick_idle">
+<span class="target" id="group___h_a_l_os_tick_1ga49888162d566db015bc264007194d506"></span>void <code class="descname">os_tick_idle</code><span class="sig-paren">(</span><a class="reference internal" href="../../../core_os/time/os_time.html#c.os_time_t" title="os_time_t">os_time_t</a><em>&nbsp;n</em><span class="sig-paren">)</span><a class="headerlink" href="#c.os_tick_idle" title="Permalink to this definition">?</a></dt>
+<dd><p>Halt CPU for up to ?n? ticks. </p>
+<p><dl class="docutils">
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">n</span></code>: The number of ticks to halt the CPU for </li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
 </div>
 </div>
 
diff --git a/develop/os/modules/hal/hal_spi/hal_spi.html b/develop/os/modules/hal/hal_spi/hal_spi.html
index 11e0f64b8..b9350f0ff 100644
--- a/develop/os/modules/hal/hal_spi/hal_spi.html
+++ b/develop/os/modules/hal/hal_spi/hal_spi.html
@@ -10,7 +10,7 @@
     
 
     
-    <title>hal_spi &mdash; Apache Mynewt 1.3.0 documentation</title>
+    <title>SPI &mdash; Apache Mynewt 1.3.0 documentation</title>
     
 
     
@@ -40,7 +40,10 @@
           <link rel="index" title="Index"
                 href="../../../../genindex.html"/>
           <link rel="search" title="Search" href="../../../../search.html"/>
-      <link rel="top" title="Apache Mynewt 1.3.0 documentation" href="../../../../index.html"/> 
+      <link rel="top" title="Apache Mynewt 1.3.0 documentation" href="../../../../index.html"/>
+          <link rel="up" title="Hardware Abstraction Layer" href="../hal.html"/>
+          <link rel="next" title="I2C" href="../hal_i2c/hal_i2c.html"/>
+          <link rel="prev" title="UART" href="../hal_uart/hal_uart.html"/> 
 
     
     <script src="../../../../_static/js/modernizr.min.js"></script>
@@ -151,7 +154,11 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
   <div class="container">
     <a href="/documentation/">Docs</a> /
     
-    hal_spi
+      <a href="../../../os_user_guide.html">OS User Guide</a> /
+    
+      <a href="../hal.html">Hardware Abstraction Layer</a> /
+    
+    SPI
     
   <div class="sourcelink">
     <a href="https://github.com/apache/mynewt-core/edit/master/docs/os/modules/hal/hal_spi/hal_spi.rst" class="icon icon-github"
@@ -211,12 +218,29 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
       
         
         
-            <ul>
+            <ul class="current">
 <li class="toctree-l1"><a class="reference internal" href="../../../../index.html">Introduction</a></li>
 <li class="toctree-l1"><a class="reference internal" href="../../../../get_started/index.html">Setup &amp; Get Started</a></li>
 <li class="toctree-l1"><a class="reference internal" href="../../../../concepts.html">Concepts</a></li>
 <li class="toctree-l1"><a class="reference internal" href="../../../../tutorials/tutorials.html">Tutorials</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../../os_user_guide.html">OS User Guide</a></li>
+<li class="toctree-l1 current"><a class="reference internal" href="../../../os_user_guide.html">OS User Guide</a><ul class="current">
+<li class="toctree-l2"><a class="reference internal" href="../../../core_os/mynewt_os.html">Kernel</a></li>
+<li class="toctree-l2 current"><a class="reference internal" href="../hal.html">Hardware Abstraction</a><ul class="current">
+<li class="toctree-l3"><a class="reference internal" href="../hal_timer/hal_timer.html">Timer</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../hal_gpio/hal_gpio.html">GPIO</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../hal_uart/hal_uart.html">UART</a></li>
+<li class="toctree-l3 current"><a class="current reference internal" href="#">SPI</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../hal_i2c/hal_i2c.html">I2C</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../hal_flash/hal_flash.html">Flash</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../hal_watchdog/hal_watchdog.html">Watchdog</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../hal_bsp/hal_bsp.html">BSP</a></li>
+</ul>
+</li>
+<li class="toctree-l2"><a class="reference internal" href="../../../core_os/porting/port_os.html">Porting Guide</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../../sysinitconfig/sysinitconfig.html">System Configuration</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../../console/console.html">Console</a></li>
+</ul>
+</li>
 <li class="toctree-l1"><a class="reference internal" href="../../../../network/ble/ble_intro.html">BLE User Guide</a></li>
 <li class="toctree-l1"><a class="reference internal" href="../../../../newt/index.html">Newt Tool Guide</a></li>
 <li class="toctree-l1"><a class="reference internal" href="../../../../newtmgr/index.html">Newt Manager Guide</a></li>
@@ -248,8 +272,8 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
                   <div role="main" class="document" itemscope="itemscope" itemtype="http://schema.org/Article">
                    <div itemprop="articleBody">
                     
-  <div class="section" id="hal-spi">
-<h1>hal_spi<a class="headerlink" href="#hal-spi" title="Permalink to this headline">?</a></h1>
+  <div class="section" id="spi">
+<h1>SPI<a class="headerlink" href="#spi" title="Permalink to this headline">?</a></h1>
 <p>SPI (Serial Peripheral Interface) is a synchronous 4-wire serial
 interface commonly used to connect components in embedded systems.</p>
 <p>For a detailed description of SPI, see
@@ -260,12 +284,8 @@ <h2>Description<a class="headerlink" href="#description" title="Permalink to thi
 blocking and non-blocking interface. SPI slave functionality is
 supported in non-blocking mode.</p>
 </div>
-<div class="section" id="definition">
-<h2>Definition<a class="headerlink" href="#definition" title="Permalink to this headline">?</a></h2>
-<p><a class="reference external" href="https://github.com/apache/incubator-mynewt-core/blob/master/hw/hal/include/hal/hal_spi.h">hal_spi.h</a></p>
-</div>
-<div class="section" id="hal-spi-theory-of-operation">
-<h2>HAL_SPI Theory Of Operation<a class="headerlink" href="#hal-spi-theory-of-operation" title="Permalink to this headline">?</a></h2>
+<div class="section" id="theory-of-operation">
+<h2>Theory Of Operation<a class="headerlink" href="#theory-of-operation" title="Permalink to this headline">?</a></h2>
 <p>SPI is called a 4-wire interface because of the 4 signals, MISO, MOSI,
 CLK, and SS. The SS signal (slave select) is an active low signal that
 activates a SPI slave device. This is how a master ?addresses? a
@@ -301,6 +321,327 @@ <h2>HAL_SPI Theory Of Operation<a class="headerlink" href="#hal-spi-theory-of-op
 <p>The Mynewt SPI HAL does not include built-in SS (Slave Select)
 signaling. It?s up to the hal_spi user to control their own SS pins.
 Typically applications will do this with GPIO.</p>
+</div>
+<div class="section" id="api">
+<h2>API<a class="headerlink" href="#api" title="Permalink to this headline">?</a></h2>
+<dl class="typedef">
+<dt id="c.hal_spi_txrx_cb">
+<span class="target" id="group___h_a_l_spi_1ga2eaa9ef4b5bdf3048b6a942462ad1ec1"></span><em class="property">typedef </em>void<code class="descname">(* hal_spi_txrx_cb)</code><span class="sig-paren">(</span>void<em>&nbsp;*arg</em>, int<em>&nbsp;len</em><span class="sig-paren">)</span><a class="headerlink" href="#c.hal_spi_txrx_cb" title="Permalink to this definition">?</a></dt>
+<dd></dd></dl>
+
+<dl class="function">
+<dt id="c.hal_spi_init">
+<span class="target" id="group___h_a_l_spi_1ga2b7019ae59d7b80d9a712221e564f2c5"></span>int <code class="descname">hal_spi_init</code><span class="sig-paren">(</span>int<em>&nbsp;spi_num</em>, void *<em>&nbsp;cfg</em>, uint8_t<em>&nbsp;spi_type</em><span class="sig-paren">)</span><a class="headerlink" href="#c.hal_spi_init" title="Permalink to this definition">?</a></dt>
+<dd><p>Initialize the SPI, given by spi_num. </p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>int 0 on success, non-zero error code on failure. </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">spi_num</span></code>: The number of the SPI to initialize </li>
+<li><code class="docutils literal notranslate"><span class="pre">cfg</span></code>: HW/MCU specific configuration, passed to the underlying implementation, providing extra configuration. </li>
+<li><code class="docutils literal notranslate"><span class="pre">spi_type</span></code>: SPI type (master or slave)</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.hal_spi_config">
+<span class="target" id="group___h_a_l_spi_1ga8546bc1ec3e14eabc80bb56319d6628e"></span>int <code class="descname">hal_spi_config</code><span class="sig-paren">(</span>int<em>&nbsp;spi_num</em>, struct  hal_spi_settings  *<em>&nbsp;psettings</em><span class="sig-paren">)</span><a class="headerlink" href="#c.hal_spi_config" title="Permalink to this definition">?</a></dt>
+<dd><p>Configure the spi. </p>
+<p>Must be called after the spi is initialized (after hal_spi_init is called) and when the spi is disabled (user must call hal_spi_disable if the spi has been enabled through hal_spi_enable prior to calling this function). Can also be used to reconfigure an initialized SPI (assuming it is disabled as described previously).</p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>int 0 on success, non-zero error code on failure. </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">spi_num</span></code>: The number of the SPI to configure. </li>
+<li><code class="docutils literal notranslate"><span class="pre">psettings</span></code>: The settings to configure this SPI with</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.hal_spi_set_txrx_cb">
+<span class="target" id="group___h_a_l_spi_1gaa87db99ce986ed1b1385590cea1f32a8"></span>int <code class="descname">hal_spi_set_txrx_cb</code><span class="sig-paren">(</span>int<em>&nbsp;spi_num</em>, <a class="reference internal" href="#c.hal_spi_txrx_cb" title="hal_spi_txrx_cb">hal_spi_txrx_cb</a><em>&nbsp;txrx_cb</em>, void *<em>&nbsp;arg</em><span class="sig-paren">)</span><a class="headerlink" href="#c.hal_spi_set_txrx_cb" title="Permalink to this definition">?</a></dt>
+<dd><p>Sets the txrx callback (executed at interrupt context) when the buffer is transferred by the master or the slave using the non-blocking API. </p>
+<p>Cannot be called when the spi is enabled. This callback will also be called when chip select is de-asserted on the slave.</p>
+<p>NOTE: This callback is only used for the non-blocking interface and must be called prior to using the non-blocking API.</p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>int 0 on success, non-zero error code on failure. </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">spi_num</span></code>: SPI interface on which to set callback </li>
+<li><code class="docutils literal notranslate"><span class="pre">txrx</span></code>: Callback function </li>
+<li><code class="docutils literal notranslate"><span class="pre">arg</span></code>: Argument to be passed to callback function</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.hal_spi_enable">
+<span class="target" id="group___h_a_l_spi_1gac20b051b9e98152804dd0801a57f1360"></span>int <code class="descname">hal_spi_enable</code><span class="sig-paren">(</span>int<em>&nbsp;spi_num</em><span class="sig-paren">)</span><a class="headerlink" href="#c.hal_spi_enable" title="Permalink to this definition">?</a></dt>
+<dd><p>Enables the SPI. </p>
+<p>This does not start a transmit or receive operation; it is used for power mgmt. Cannot be called when a SPI transfer is in progress.</p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>int 0 on success, non-zero error code on failure. </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">spi_num</span></code>: </li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.hal_spi_disable">
+<span class="target" id="group___h_a_l_spi_1gae2fca841a1ac4dd055e6247449bf45ab"></span>int <code class="descname">hal_spi_disable</code><span class="sig-paren">(</span>int<em>&nbsp;spi_num</em><span class="sig-paren">)</span><a class="headerlink" href="#c.hal_spi_disable" title="Permalink to this definition">?</a></dt>
+<dd><p>Disables the SPI. </p>
+<p>Used for power mgmt. It will halt any current SPI transfers in progress.</p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>int 0 on success, non-zero error code on failure. </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">spi_num</span></code>: </li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.hal_spi_tx_val">
+<span class="target" id="group___h_a_l_spi_1gafae520402e8829bbbca450f504851cd5"></span>uint16_t <code class="descname">hal_spi_tx_val</code><span class="sig-paren">(</span>int<em>&nbsp;spi_num</em>, uint16_t<em>&nbsp;val</em><span class="sig-paren">)</span><a class="headerlink" href="#c.hal_spi_tx_val" title="Permalink to this definition">?</a></dt>
+<dd><p>Blocking call to send a value on the SPI. </p>
+<p>Returns the value received from the SPI slave.</p>
+<p>MASTER: Sends the value and returns the received value from the slave. SLAVE: Invalid API. Returns 0xFFFF</p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>uint16_t Value received on SPI interface from slave. Returns 0xFFFF if called when the SPI is configured to be a slave </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">spi_num</span></code>: Spi interface to use </li>
+<li><code class="docutils literal notranslate"><span class="pre">val</span></code>: Value to send</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.hal_spi_txrx">
+<span class="target" id="group___h_a_l_spi_1ga553da06a116ddadf0df93343f51f1432"></span>int <code class="descname">hal_spi_txrx</code><span class="sig-paren">(</span>int<em>&nbsp;spi_num</em>, void *<em>&nbsp;txbuf</em>, void *<em>&nbsp;rxbuf</em>, int<em>&nbsp;cnt</em><span class="sig-paren">)</span><a class="headerlink" href="#c.hal_spi_txrx" title="Permalink to this definition">?</a></dt>
+<dd><p>Blocking interface to send a buffer and store the received values from the slave. </p>
+<p>The transmit and receive buffers are either arrays of 8-bit (uint8_t) values or 16-bit values depending on whether the spi is configured for 8 bit data or more than 8 bits per value. The ?cnt? parameter is the number of 8-bit or 16-bit values. Thus, if ?cnt? is 10, txbuf/rxbuf would point to an array of size 10 (in bytes) if the SPI is using 8-bit data; otherwise txbuf/rxbuf would point to an array of size 20 bytes (ten, uint16_t values).</p>
+<p>NOTE: these buffers are in the native endian-ness of the platform. <div class="highlight-none notranslate"><div class="highlight"><pre><span></span>MASTER: master sends all the values in the buffer and stores the
+        stores the values in the receive buffer if rxbuf is not NULL.
+        The txbuf parameter cannot be NULL.
+SLAVE: cannot be called for a slave; returns -1
+</pre></div>
+</div>
+</p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>int 0 on success, non-zero error code on failure. </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">spi_num</span></code>: SPI interface to use </li>
+<li><code class="docutils literal notranslate"><span class="pre">txbuf</span></code>: Pointer to buffer where values to transmit are stored. </li>
+<li><code class="docutils literal notranslate"><span class="pre">rxbuf</span></code>: Pointer to buffer to store values received from peer. </li>
+<li><code class="docutils literal notranslate"><span class="pre">cnt</span></code>: Number of 8-bit or 16-bit values to be transferred.</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.hal_spi_txrx_noblock">
+<span class="target" id="group___h_a_l_spi_1gaf63f67ca8a93d7c93061565e9be1385b"></span>int <code class="descname">hal_spi_txrx_noblock</code><span class="sig-paren">(</span>int<em>&nbsp;spi_num</em>, void *<em>&nbsp;txbuf</em>, void *<em>&nbsp;rxbuf</em>, int<em>&nbsp;cnt</em><span class="sig-paren">)</span><a class="headerlink" href="#c.hal_spi_txrx_noblock" title="Permalink to this definition">?</a></dt>
+<dd><p>Non-blocking interface to send a buffer and store received values. </p>
+<p>Can be used for both master and slave SPI types. The user must configure the callback (using hal_spi_set_txrx_cb); the txrx callback is executed at interrupt context when the buffer is sent.</p>
+<p>The transmit and receive buffers are either arrays of 8-bit (uint8_t) values or 16-bit values depending on whether the spi is configured for 8 bit data or more than 8 bits per value. The ?cnt? parameter is the number of 8-bit or 16-bit values. Thus, if ?cnt? is 10, txbuf/rxbuf would point to an array of size 10 (in bytes) if the SPI is using 8-bit data; otherwise txbuf/rxbuf would point to an array of size 20 bytes (ten, uint16_t values).</p>
+<p>NOTE: these buffers are in the native endian-ness of the platform. <div class="highlight-none notranslate"><div class="highlight"><pre><span></span>MASTER: master sends all the values in the buffer and stores the
+        stores the values in the receive buffer if rxbuf is not NULL.
+        The txbuf parameter cannot be NULL
+SLAVE: Slave &quot;preloads&quot; the data to be sent to the master (values
+       stored in txbuf) and places received data from master in rxbuf
+       (if not NULL). The txrx callback occurs when len values are
+       transferred or master de-asserts chip select. If txbuf is NULL,
+       the slave transfers its default byte. Both rxbuf and txbuf cannot
+       be NULL.
+</pre></div>
+</div>
+</p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>int 0 on success, non-zero error code on failure. </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">spi_num</span></code>: SPI interface to use </li>
+<li><code class="docutils literal notranslate"><span class="pre">txbuf</span></code>: Pointer to buffer where values to transmit are stored. </li>
+<li><code class="docutils literal notranslate"><span class="pre">rxbuf</span></code>: Pointer to buffer to store values received from peer. </li>
+<li><code class="docutils literal notranslate"><span class="pre">cnt</span></code>: Number of 8-bit or 16-bit values to be transferred.</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.hal_spi_slave_set_def_tx_val">
+<span class="target" id="group___h_a_l_spi_1gadc32383878ad19d66fac43f6b011991e"></span>int <code class="descname">hal_spi_slave_set_def_tx_val</code><span class="sig-paren">(</span>int<em>&nbsp;spi_num</em>, uint16_t<em>&nbsp;val</em><span class="sig-paren">)</span><a class="headerlink" href="#c.hal_spi_slave_set_def_tx_val" title="Permalink to this definition">?</a></dt>
+<dd><p>Sets the default value transferred by the slave. </p>
+<p>Not valid for master</p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>int 0 on success, non-zero error code on failure. </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">spi_num</span></code>: SPI interface to use</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.hal_spi_abort">
+<span class="target" id="group___h_a_l_spi_1gaf9e6514439403074fb2cb9ebd5929639"></span>int <code class="descname">hal_spi_abort</code><span class="sig-paren">(</span>int<em>&nbsp;spi_num</em><span class="sig-paren">)</span><a class="headerlink" href="#c.hal_spi_abort" title="Permalink to this definition">?</a></dt>
+<dd><p>This aborts the current transfer but keeps the spi enabled. </p>
+<p>
+NOTE: does not return an error if no transfer was in progress. <dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>int 0 on success, non-zero error code on failure.</dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">spi_num</span></code>: SPI interface on which transfer should be aborted.</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.hal_spi_data_mode_breakout">
+<span class="target" id="group___h_a_l_spi_1ga4a51284d7a86783244406751de4c6b14"></span>int <code class="descname">hal_spi_data_mode_breakout</code><span class="sig-paren">(</span>uint8_t<em>&nbsp;data_mode</em>, int *<em>&nbsp;out_cpol</em>, int *<em>&nbsp;out_cpha</em><span class="sig-paren">)</span><a class="headerlink" href="#c.hal_spi_data_mode_breakout" title="Permalink to this definition">?</a></dt>
+<dd><p>Extracts CPOL and CPHA values from a data-mode constant. </p>
+<p>Utility function, defined once for every MCU.</p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>0 on success; nonzero on invalid input. </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">data_mode</span></code>: The HAL_SPI_MODE value to convert. </li>
+<li><code class="docutils literal notranslate"><span class="pre">out_cpol</span></code>: The CPOL gets written here on success. </li>
+<li><code class="docutils literal notranslate"><span class="pre">out_cpha</span></code>: The CPHA gets written here on success.</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="define">
+<dt id="c.HAL_SPI_TYPE_MASTER">
+<span class="target" id="group___h_a_l_spi_1gaa9052e61a231f7317781cd6a4ffe8b5e"></span><code class="descname">HAL_SPI_TYPE_MASTER</code><a class="headerlink" href="#c.HAL_SPI_TYPE_MASTER" title="Permalink to this definition">?</a></dt>
+<dd></dd></dl>
+
+<dl class="define">
+<dt id="c.HAL_SPI_TYPE_SLAVE">
+<span class="target" id="group___h_a_l_spi_1gaaee6eee2ec864affda97df74eb55933f"></span><code class="descname">HAL_SPI_TYPE_SLAVE</code><a class="headerlink" href="#c.HAL_SPI_TYPE_SLAVE" title="Permalink to this definition">?</a></dt>
+<dd></dd></dl>
+
+<dl class="define">
+<dt id="c.HAL_SPI_MODE0">
+<span class="target" id="group___h_a_l_spi_1gaf269bbeaf787deae7de03b7e1c8ede4f"></span><code class="descname">HAL_SPI_MODE0</code><a class="headerlink" href="#c.HAL_SPI_MODE0" title="Permalink to this definition">?</a></dt>
+<dd><p>SPI mode 0. </p>
+</dd></dl>
+
+<dl class="define">
+<dt id="c.HAL_SPI_MODE1">
+<span class="target" id="group___h_a_l_spi_1gaa4fae1c5b56c54e8bb905d4774b6c21e"></span><code class="descname">HAL_SPI_MODE1</code><a class="headerlink" href="#c.HAL_SPI_MODE1" title="Permalink to this definition">?</a></dt>
+<dd><p>SPI mode 1. </p>
+</dd></dl>
+
+<dl class="define">
+<dt id="c.HAL_SPI_MODE2">
+<span class="target" id="group___h_a_l_spi_1ga9a4f7a6b535bf91c6d9eadc94876b3ab"></span><code class="descname">HAL_SPI_MODE2</code><a class="headerlink" href="#c.HAL_SPI_MODE2" title="Permalink to this definition">?</a></dt>
+<dd><p>SPI mode 2. </p>
+</dd></dl>
+
+<dl class="define">
+<dt id="c.HAL_SPI_MODE3">
+<span class="target" id="group___h_a_l_spi_1gab3d553cb6ad796c81cf8da03fd162410"></span><code class="descname">HAL_SPI_MODE3</code><a class="headerlink" href="#c.HAL_SPI_MODE3" title="Permalink to this definition">?</a></dt>
+<dd><p>SPI mode 3. </p>
+</dd></dl>
+
+<dl class="define">
+<dt id="c.HAL_SPI_MSB_FIRST">
+<span class="target" id="group___h_a_l_spi_1ga141f16a65d039c8587710056aa4bcf61"></span><code class="descname">HAL_SPI_MSB_FIRST</code><a class="headerlink" href="#c.HAL_SPI_MSB_FIRST" title="Permalink to this definition">?</a></dt>
+<dd><p>SPI data order, most significant bit first. </p>
+</dd></dl>
+
+<dl class="define">
+<dt id="c.HAL_SPI_LSB_FIRST">
+<span class="target" id="group___h_a_l_spi_1gad78a641f633979ca311bf4adb0c3c282"></span><code class="descname">HAL_SPI_LSB_FIRST</code><a class="headerlink" href="#c.HAL_SPI_LSB_FIRST" title="Permalink to this definition">?</a></dt>
+<dd><p>SPI data order, least significant bit first. </p>
+</dd></dl>
+
+<dl class="define">
+<dt id="c.HAL_SPI_WORD_SIZE_8BIT">
+<span class="target" id="group___h_a_l_spi_1gac0c2a0f9c70877319df3eda695953b7c"></span><code class="descname">HAL_SPI_WORD_SIZE_8BIT</code><a class="headerlink" href="#c.HAL_SPI_WORD_SIZE_8BIT" title="Permalink to this definition">?</a></dt>
+<dd><p>SPI word size 8 bit. </p>
+</dd></dl>
+
+<dl class="define">
+<dt id="c.HAL_SPI_WORD_SIZE_9BIT">
+<span class="target" id="group___h_a_l_spi_1gad6372e8ec76058a16520e19fe33c1841"></span><code class="descname">HAL_SPI_WORD_SIZE_9BIT</code><a class="headerlink" href="#c.HAL_SPI_WORD_SIZE_9BIT" title="Permalink to this definition">?</a></dt>
+<dd><p>SPI word size 9 bit. </p>
+</dd></dl>
+
+<dl class="class">
+<dt id="_CPPv316hal_spi_settings">
+<span id="_CPPv216hal_spi_settings"></span><span id="hal_spi_settings"></span><span class="target" id="structhal__spi__settings"></span><em class="property">struct </em><code class="descname">hal_spi_settings</code><a class="headerlink" href="#_CPPv316hal_spi_settings" title="Permalink to this definition">?</a><br /></dt>
+<dd><em>#include &lt;hal_spi.h&gt;</em><p>since one spi device can control multiple devices, some configuration can be changed on the fly from the hal </p>
+<div class="breathe-sectiondef docutils container">
+<p class="breathe-sectiondef-title rubric">Public Members</p>
+<dl class="variable">
+<dt id="c.hal_spi_settings::data_mode">
+<span class="target" id="structhal__spi__settings_1a7c948a0d643cf02d65afb68479c27525"></span>uint8_t <code class="descname">data_mode</code><a class="headerlink" href="#c.hal_spi_settings::data_mode" title="Permalink to this definition">?</a></dt>
+<dd><p>Data mode of SPI driver, defined by HAL_SPI_MODEn. </p>
+</dd></dl>
+
+<dl class="variable">
+<dt id="c.hal_spi_settings::data_order">
+<span class="target" id="structhal__spi__settings_1a8604e51cedd73c00d9ec91f3a77429e6"></span>uint8_t <code class="descname">data_order</code><a class="headerlink" href="#c.hal_spi_settings::data_order" title="Permalink to this definition">?</a></dt>
+<dd><p>Data order, either HAL_SPI_MSB_FIRST or HAL_SPI_LSB_FIRST. </p>
+</dd></dl>
+
+<dl class="variable">
+<dt id="c.hal_spi_settings::word_size">
+<span class="target" id="structhal__spi__settings_1ab609e05b0ae7b008b28a06dd9baba450"></span>uint8_t <code class="descname">word_size</code><a class="headerlink" href="#c.hal_spi_settings::word_size" title="Permalink to this definition">?</a></dt>
+<dd><p>The word size of the SPI transaction, either 8-bit or 9-bit. </p>
+</dd></dl>
+
+<dl class="variable">
+<dt id="c.hal_spi_settings::baudrate">
+<span class="target" id="structhal__spi__settings_1a3e1c672197908a71a947c5c9cc94236c"></span>uint32_t <code class="descname">baudrate</code><a class="headerlink" href="#c.hal_spi_settings::baudrate" title="Permalink to this definition">?</a></dt>
+<dd><p>Baudrate in kHz. </p>
+</dd></dl>
+
+</div>
+</dd></dl>
+
 </div>
 </div>
 
@@ -308,6 +649,15 @@ <h2>HAL_SPI Theory Of Operation<a class="headerlink" href="#hal-spi-theory-of-op
                    </div>
                   </div>
                   
+    <div class="rst-footer-buttons row" role="navigation" aria-label="footer navigation">
+      
+        <a href="../hal_i2c/hal_i2c.html" class="btn btn-neutral float-right" title="I2C" accesskey="n">Next: I2C <span class="fa fa-arrow-circle-right"></span></a>
+      
+      
+        <a href="../hal_uart/hal_uart.html" class="btn btn-neutral" title="UART" accesskey="p"><span class="fa fa-arrow-circle-left"></span> Previous: UART</a>
+      
+    </div>
+
                 </div>
               </div>
             </div>
diff --git a/develop/os/modules/hal/hal_system/hal_sys.html b/develop/os/modules/hal/hal_system/hal_sys.html
index 450290d9c..1cae35d99 100644
--- a/develop/os/modules/hal/hal_system/hal_sys.html
+++ b/develop/os/modules/hal/hal_system/hal_sys.html
@@ -10,7 +10,7 @@
     
 
     
-    <title>hal_system &mdash; Apache Mynewt 1.3.0 documentation</title>
+    <title>System &mdash; Apache Mynewt 1.3.0 documentation</title>
     
 
     
@@ -151,7 +151,7 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
   <div class="container">
     <a href="/documentation/">Docs</a> /
     
-    hal_system
+    System
     
   <div class="sourcelink">
     <a href="https://github.com/apache/mynewt-core/edit/master/docs/os/modules/hal/hal_system/hal_sys.rst" class="icon icon-github"
@@ -248,8 +248,8 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
                   <div role="main" class="document" itemscope="itemscope" itemtype="http://schema.org/Article">
                    <div itemprop="articleBody">
                     
-  <div class="section" id="hal-system">
-<h1>hal_system<a class="headerlink" href="#hal-system" title="Permalink to this headline">?</a></h1>
+  <div class="section" id="system">
+<h1>System<a class="headerlink" href="#system" title="Permalink to this headline">?</a></h1>
 <p>A hardware independent interface for starting and resetting the system.</p>
 <div class="section" id="description">
 <h2>Description<a class="headerlink" href="#description" title="Permalink to this headline">?</a></h2>
@@ -260,12 +260,92 @@ <h2>Description<a class="headerlink" href="#description" title="Permalink to thi
 <code class="docutils literal notranslate"><span class="pre">/hw/mcu/nordic/nrf52xxx/src/</span></code> directory for Nordic nRF52 series of
 chips.</p>
 </div>
-<div class="section" id="definition">
-<h2>Definition<a class="headerlink" href="#definition" title="Permalink to this headline">?</a></h2>
-<p><a class="reference external" href="https://github.com/apache/incubator-mynewt-core/blob/master/hw/hal/include/hal/hal_system.h">hal_system.h</a></p>
-</div>
-<div class="section" id="examples">
-<h2>Examples<a class="headerlink" href="#examples" title="Permalink to this headline">?</a></h2>
+<div class="section" id="api">
+<h2>API<a class="headerlink" href="#api" title="Permalink to this headline">?</a></h2>
+<dl class="enum">
+<dt id="c.HALSystem::hal_reset_reason">
+<span class="target" id="group___h_a_l_system_1ga09b5ea025a6a638b45a7276b1e572924"></span><em class="property">enum </em><code class="descclassname">HALSystem::</code><code class="descname">hal_reset_reason</code><a class="headerlink" href="#c.HALSystem::hal_reset_reason" title="Permalink to this definition">?</a></dt>
+<dd><p>Reboot reason. </p>
+<p><em>Values:</em></p>
+<dl class="enumvalue">
+<dt id="c.HALSystem::HAL_RESET_POR">
+<span class="target" id="group___h_a_l_system_1gga09b5ea025a6a638b45a7276b1e572924a0f0d1b68f623da5384b142a5ffef142a"></span><code class="descname">HAL_RESET_POR</code> = 1<a class="headerlink" href="#c.HALSystem::HAL_RESET_POR" title="Permalink to this definition">?</a></dt>
+<dd><p>Power on Reset. </p>
+</dd></dl>
+
+<dl class="enumvalue">
+<dt id="c.HALSystem::HAL_RESET_PIN">
+<span class="target" id="group___h_a_l_system_1gga09b5ea025a6a638b45a7276b1e572924a8d2581c07d1dfde7244d5b09ecfdd1ce"></span><code class="descname">HAL_RESET_PIN</code> = 2<a class="headerlink" href="#c.HALSystem::HAL_RESET_PIN" title="Permalink to this definition">?</a></dt>
+<dd><p>Caused by Reset Pin. </p>
+</dd></dl>
+
+<dl class="enumvalue">
+<dt id="c.HALSystem::HAL_RESET_WATCHDOG">
+<span class="target" id="group___h_a_l_system_1gga09b5ea025a6a638b45a7276b1e572924a69a2e98907a3824bd58513a162940a84"></span><code class="descname">HAL_RESET_WATCHDOG</code> = 3<a class="headerlink" href="#c.HALSystem::HAL_RESET_WATCHDOG" title="Permalink to this definition">?</a></dt>
+<dd><p>Caused by Watchdog. </p>
+</dd></dl>
+
+<dl class="enumvalue">
+<dt id="c.HALSystem::HAL_RESET_SOFT">
+<span class="target" id="group___h_a_l_system_1gga09b5ea025a6a638b45a7276b1e572924abb5acfff3c2b181ad87a781918ca5526"></span><code class="descname">HAL_RESET_SOFT</code> = 4<a class="headerlink" href="#c.HALSystem::HAL_RESET_SOFT" title="Permalink to this definition">?</a></dt>
+<dd><p>Soft reset, either system reset or crash. </p>
+</dd></dl>
+
+<dl class="enumvalue">
+<dt id="c.HALSystem::HAL_RESET_BROWNOUT">
+<span class="target" id="group___h_a_l_system_1gga09b5ea025a6a638b45a7276b1e572924a54dd29c8d0eb2b272bde3294a2e48a3c"></span><code class="descname">HAL_RESET_BROWNOUT</code> = 5<a class="headerlink" href="#c.HALSystem::HAL_RESET_BROWNOUT" title="Permalink to this definition">?</a></dt>
+<dd><p>Low supply voltage. </p>
+</dd></dl>
+
+<dl class="enumvalue">
+<dt id="c.HALSystem::HAL_RESET_REQUESTED">
+<span class="target" id="group___h_a_l_system_1gga09b5ea025a6a638b45a7276b1e572924abf3b4b4329a9afc456c43f9ceb227dd3"></span><code class="descname">HAL_RESET_REQUESTED</code> = 6<a class="headerlink" href="#c.HALSystem::HAL_RESET_REQUESTED" title="Permalink to this definition">?</a></dt>
+<dd><p>Restart due to user request. </p>
+</dd></dl>
+
+</dd></dl>
+
+<dl class="function">
+<dt id="c.hal_system_reset">
+<span class="target" id="group___h_a_l_system_1ga298b06e8955f8c64886e851dffe2dd96"></span>void <code class="descname">hal_system_reset</code><span class="sig-paren">(</span>void<span class="sig-paren">)</span><a class="headerlink" href="#c.hal_system_reset" title="Permalink to this definition">?</a></dt>
+<dd><p>System reset. </p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.hal_system_start">
+<span class="target" id="group___h_a_l_system_1ga0edf69888576dcebf13be54592322286"></span>void <code class="descname">hal_system_start</code><span class="sig-paren">(</span>void *<em>&nbsp;img_start</em><span class="sig-paren">)</span><a class="headerlink" href="#c.hal_system_start" title="Permalink to this definition">?</a></dt>
+<dd><p>Called by bootloader to start loaded program. </p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.hal_system_restart">
+<span class="target" id="group___h_a_l_system_1ga98fc967d38f29dd2c1388ccdf13f0fe5"></span>void <code class="descname">hal_system_restart</code><span class="sig-paren">(</span>void *<em>&nbsp;img_start</em><span class="sig-paren">)</span><a class="headerlink" href="#c.hal_system_restart" title="Permalink to this definition">?</a></dt>
+<dd><p>Called by split app loader to start the app program. </p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.hal_debugger_connected">
+<span class="target" id="group___h_a_l_system_1gad043ab91f977ec307638f6ecc309dfdb"></span>int <code class="descname">hal_debugger_connected</code><span class="sig-paren">(</span>void<span class="sig-paren">)</span><a class="headerlink" href="#c.hal_debugger_connected" title="Permalink to this definition">?</a></dt>
+<dd><p>Returns non-zero if there is a HW debugger attached. </p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.hal_reset_cause">
+<span class="target" id="group___h_a_l_system_1gaa5c34b0ed27b5b987eac78702c671854"></span>enum hal_reset_reason <code class="descname">hal_reset_cause</code><span class="sig-paren">(</span>void<span class="sig-paren">)</span><a class="headerlink" href="#c.hal_reset_cause" title="Permalink to this definition">?</a></dt>
+<dd><p>Return the reboot reason. </p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>A reboot reason </dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.hal_system_clock_start">
+<span class="target" id="group___h_a_l_system_1ga40d3f16e48773bf0c4cfa7b79b31b6f8"></span>void <code class="descname">hal_system_clock_start</code><span class="sig-paren">(</span>void<span class="sig-paren">)</span><a class="headerlink" href="#c.hal_system_clock_start" title="Permalink to this definition">?</a></dt>
+<dd><p>Starts clocks needed by system. </p>
+</dd></dl>
+
 </div>
 </div>
 
diff --git a/develop/os/modules/hal/hal_timer/hal_timer.html b/develop/os/modules/hal/hal_timer/hal_timer.html
index f157a7650..634a1b2bd 100644
--- a/develop/os/modules/hal/hal_timer/hal_timer.html
+++ b/develop/os/modules/hal/hal_timer/hal_timer.html
@@ -10,7 +10,7 @@
     
 
     
-    <title>hal_timer &mdash; Apache Mynewt 1.3.0 documentation</title>
+    <title>Timer &mdash; Apache Mynewt 1.3.0 documentation</title>
     
 
     
@@ -40,7 +40,10 @@
           <link rel="index" title="Index"
                 href="../../../../genindex.html"/>
           <link rel="search" title="Search" href="../../../../search.html"/>
-      <link rel="top" title="Apache Mynewt 1.3.0 documentation" href="../../../../index.html"/> 
+      <link rel="top" title="Apache Mynewt 1.3.0 documentation" href="../../../../index.html"/>
+          <link rel="up" title="Hardware Abstraction Layer" href="../hal.html"/>
+          <link rel="next" title="GPIO" href="../hal_gpio/hal_gpio.html"/>
+          <link rel="prev" title="Hardware Abstraction Layer" href="../hal.html"/> 
 
     
     <script src="../../../../_static/js/modernizr.min.js"></script>
@@ -151,7 +154,11 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
   <div class="container">
     <a href="/documentation/">Docs</a> /
     
-    hal_timer
+      <a href="../../../os_user_guide.html">OS User Guide</a> /
+    
+      <a href="../hal.html">Hardware Abstraction Layer</a> /
+    
+    Timer
     
   <div class="sourcelink">
     <a href="https://github.com/apache/mynewt-core/edit/master/docs/os/modules/hal/hal_timer/hal_timer.rst" class="icon icon-github"
@@ -211,12 +218,29 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
       
         
         
-            <ul>
+            <ul class="current">
 <li class="toctree-l1"><a class="reference internal" href="../../../../index.html">Introduction</a></li>
 <li class="toctree-l1"><a class="reference internal" href="../../../../get_started/index.html">Setup &amp; Get Started</a></li>
 <li class="toctree-l1"><a class="reference internal" href="../../../../concepts.html">Concepts</a></li>
 <li class="toctree-l1"><a class="reference internal" href="../../../../tutorials/tutorials.html">Tutorials</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../../os_user_guide.html">OS User Guide</a></li>
+<li class="toctree-l1 current"><a class="reference internal" href="../../../os_user_guide.html">OS User Guide</a><ul class="current">
+<li class="toctree-l2"><a class="reference internal" href="../../../core_os/mynewt_os.html">Kernel</a></li>
+<li class="toctree-l2 current"><a class="reference internal" href="../hal.html">Hardware Abstraction</a><ul class="current">
+<li class="toctree-l3 current"><a class="current reference internal" href="#">Timer</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../hal_gpio/hal_gpio.html">GPIO</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../hal_uart/hal_uart.html">UART</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../hal_spi/hal_spi.html">SPI</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../hal_i2c/hal_i2c.html">I2C</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../hal_flash/hal_flash.html">Flash</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../hal_watchdog/hal_watchdog.html">Watchdog</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../hal_bsp/hal_bsp.html">BSP</a></li>
+</ul>
+</li>
+<li class="toctree-l2"><a class="reference internal" href="../../../core_os/porting/port_os.html">Porting Guide</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../../sysinitconfig/sysinitconfig.html">System Configuration</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../../console/console.html">Console</a></li>
+</ul>
+</li>
 <li class="toctree-l1"><a class="reference internal" href="../../../../network/ble/ble_intro.html">BLE User Guide</a></li>
 <li class="toctree-l1"><a class="reference internal" href="../../../../newt/index.html">Newt Tool Guide</a></li>
 <li class="toctree-l1"><a class="reference internal" href="../../../../newtmgr/index.html">Newt Manager Guide</a></li>
@@ -248,8 +272,8 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
                   <div role="main" class="document" itemscope="itemscope" itemtype="http://schema.org/Article">
                    <div itemprop="articleBody">
                     
-  <div class="section" id="hal-timer">
-<h1>hal_timer<a class="headerlink" href="#hal-timer" title="Permalink to this headline">?</a></h1>
+  <div class="section" id="timer">
+<h1>Timer<a class="headerlink" href="#timer" title="Permalink to this headline">?</a></h1>
 <p>The hardware independent timer structure and API to configure,
 initialize, and run timers.</p>
 <div class="section" id="description">
@@ -272,12 +296,215 @@ <h2>Description<a class="headerlink" href="#description" title="Permalink to thi
 </pre></div>
 </div>
 </div>
-<div class="section" id="definition">
-<h2>Definition<a class="headerlink" href="#definition" title="Permalink to this headline">?</a></h2>
-<p><a class="reference external" href="https://github.com/apache/incubator-mynewt-core/blob/master/hw/hal/include/hal/hal_timer.h">hal_timer.h</a></p>
+<div class="section" id="api">
+<h2>API<a class="headerlink" href="#api" title="Permalink to this headline">?</a></h2>
+<dl class="typedef">
+<dt id="c.hal_timer_cb">
+<span class="target" id="group___h_a_l_timer_1gaf6b777c97781df4e860d4eadba407ec4"></span><em class="property">typedef </em>void<code class="descname">(* hal_timer_cb)</code><span class="sig-paren">(</span>void<em>&nbsp;*arg</em><span class="sig-paren">)</span><a class="headerlink" href="#c.hal_timer_cb" title="Permalink to this definition">?</a></dt>
+<dd></dd></dl>
+
+<dl class="function">
+<dt id="c.hal_timer_init">
+<span class="target" id="group___h_a_l_timer_1gae008bd575e17e5c0d6fab7cd20429505"></span>int <code class="descname">hal_timer_init</code><span class="sig-paren">(</span>int<em>&nbsp;timer_num</em>, void *<em>&nbsp;cfg</em><span class="sig-paren">)</span><a class="headerlink" href="#c.hal_timer_init" title="Permalink to this definition">?</a></dt>
+<dd><p>Initialize a HW timer. </p>
+<p><dl class="docutils">
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">timer_num</span></code>: The number of the HW timer to initialize </li>
+<li><code class="docutils literal notranslate"><span class="pre">cfg</span></code>: Hardware specific timer configuration. This is passed from BSP directly to the MCU specific driver. </li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.hal_timer_deinit">
+<span class="target" id="group___h_a_l_timer_1gab484bcc8f328f16a467ba74473bc4e67"></span>int <code class="descname">hal_timer_deinit</code><span class="sig-paren">(</span>int<em>&nbsp;timer_num</em><span class="sig-paren">)</span><a class="headerlink" href="#c.hal_timer_deinit" title="Permalink to this definition">?</a></dt>
+<dd><p>Un-initialize a HW timer. </p>
+<p><dl class="docutils">
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">timer_num</span></code>: The number of the HW timer to un-initialize </li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.hal_timer_config">
+<span class="target" id="group___h_a_l_timer_1gafc13bd55373f7b105c1f09a319876c86"></span>int <code class="descname">hal_timer_config</code><span class="sig-paren">(</span>int<em>&nbsp;timer_num</em>, uint32_t<em>&nbsp;freq_hz</em><span class="sig-paren">)</span><a class="headerlink" href="#c.hal_timer_config" title="Permalink to this definition">?</a></dt>
+<dd><p>Config a HW timer at the given frequency and start it. </p>
+<p>If the exact frequency is not obtainable the closest obtainable frequency is set.</p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>0 on success, non-zero error code on failure </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">timer_num</span></code>: The number of the HW timer to configure </li>
+<li><code class="docutils literal notranslate"><span class="pre">freq_hz</span></code>: The frequency in Hz to configure the timer at</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.hal_timer_get_resolution">
+<span class="target" id="group___h_a_l_timer_1ga09972cb40f65bbf75add4a745bb6f171"></span>uint32_t <code class="descname">hal_timer_get_resolution</code><span class="sig-paren">(</span>int<em>&nbsp;timer_num</em><span class="sig-paren">)</span><a class="headerlink" href="#c.hal_timer_get_resolution" title="Permalink to this definition">?</a></dt>
+<dd><p>Returns the resolution of the HW timer. </p>
+<p>NOTE: the frequency may not be obtainable so the caller can use this to determine the resolution. Returns resolution in nanoseconds. A return value of 0 indicates an invalid timer was used.</p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>The resolution of the timer </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">timer_num</span></code>: The number of the HW timer to get resolution for</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.hal_timer_read">
+<span class="target" id="group___h_a_l_timer_1ga399c1ad97a20ab9a4edb445ea6253b59"></span>uint32_t <code class="descname">hal_timer_read</code><span class="sig-paren">(</span>int<em>&nbsp;timer_num</em><span class="sig-paren">)</span><a class="headerlink" href="#c.hal_timer_read" title="Permalink to this definition">?</a></dt>
+<dd><p>Returns the HW timer current tick value. </p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>The current tick value </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">timer_num</span></code>: The HW timer to read the tick value from</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.hal_timer_delay">
+<span class="target" id="group___h_a_l_timer_1ga8921d021217ad28b7c399dfac948072d"></span>int <code class="descname">hal_timer_delay</code><span class="sig-paren">(</span>int<em>&nbsp;timer_num</em>, uint32_t<em>&nbsp;ticks</em><span class="sig-paren">)</span><a class="headerlink" href="#c.hal_timer_delay" title="Permalink to this definition">?</a></dt>
+<dd><p>Perform a blocking delay for a number of ticks. </p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>0 on success, non-zero error code on failure </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">timer_num</span></code>: The timer number to use for the blocking delay </li>
+<li><code class="docutils literal notranslate"><span class="pre">ticks</span></code>: The number of ticks to delay for</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.hal_timer_set_cb">
+<span class="target" id="group___h_a_l_timer_1ga565e77630c3548207bb1cde8545230fd"></span>int <code class="descname">hal_timer_set_cb</code><span class="sig-paren">(</span>int<em>&nbsp;timer_num</em>, struct  hal_timer  *<em>&nbsp;tmr</em>, <a class="reference internal" href="#c.hal_timer_cb" title="hal_timer_cb">hal_timer_cb</a><em>&nbsp;cb_func</em>, void *<em>&nbsp;arg</em><span class="sig-paren">)</span><a class="headerlink" href="#c.hal_timer_set_cb" title="Permalink to this definition">?</a></dt>
+<dd><p>Set the timer structure prior to use. </p>
+<p>Should not be called if the timer is running. Must be called at least once prior to using timer.</p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>0 on success, non-zero error code on failure. </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">timer_num</span></code>: The number of the HW timer to configure the callback on </li>
+<li><code class="docutils literal notranslate"><span class="pre">tmr</span></code>: The timer structure to use for this timer </li>
+<li><code class="docutils literal notranslate"><span class="pre">cb_func</span></code>: The timer callback to call when the timer fires </li>
+<li><code class="docutils literal notranslate"><span class="pre">arg</span></code>: An opaque argument to provide the timer callback</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.hal_timer_start">
+<span class="target" id="group___h_a_l_timer_1ga108e679ed0440ac830631fc662a04fa6"></span>int <code class="descname">hal_timer_start</code><span class="sig-paren">(</span>struct  hal_timer  *<em>&nbsp;tmr</em>, uint32_t<em>&nbsp;ticks</em><span class="sig-paren">)</span><a class="headerlink" href="#c.hal_timer_start" title="Permalink to this definition">?</a></dt>
+<dd><p>Start a timer that will expire in ?ticks? ticks. </p>
+<p>Ticks cannot be 0</p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>0 on success, non-zero error code on failure. </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">tmr</span></code>: The timer to start </li>
+<li><code class="docutils literal notranslate"><span class="pre">ticks</span></code>: The number of ticks to expire the timer in</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.hal_timer_start_at">
+<span class="target" id="group___h_a_l_timer_1ga7cfacab8052286bcb9ebcf09fe4ba842"></span>int <code class="descname">hal_timer_start_at</code><span class="sig-paren">(</span>struct  hal_timer  *<em>&nbsp;tmr</em>, uint32_t<em>&nbsp;tick</em><span class="sig-paren">)</span><a class="headerlink" href="#c.hal_timer_start_at" title="Permalink to this definition">?</a></dt>
+<dd><p>Start a timer that will expire when the timer reaches ?tick?. </p>
+<p>If tick has already passed the timer callback will be called ?immediately? (at interrupt context).</p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>0 on success, non-zero error code on failure. </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">tmr</span></code>: The timer to start </li>
+<li><code class="docutils literal notranslate"><span class="pre">tick</span></code>: The absolute tick value to fire the timer at</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.hal_timer_stop">
+<span class="target" id="group___h_a_l_timer_1ga948dc3fdc14f840fe713ffc1f9508dab"></span>int <code class="descname">hal_timer_stop</code><span class="sig-paren">(</span>struct  hal_timer  *<em>&nbsp;tmr</em><span class="sig-paren">)</span><a class="headerlink" href="#c.hal_timer_stop" title="Permalink to this definition">?</a></dt>
+<dd><p>Stop a currently running timer; associated callback will NOT be called. </p>
+<p><dl class="docutils">
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">tmr</span></code>: The timer to stop </li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="class">
+<dt id="_CPPv39hal_timer">
+<span id="_CPPv29hal_timer"></span><span id="hal_timer"></span><span class="target" id="structhal__timer"></span><em class="property">struct </em><code class="descname">hal_timer</code><a class="headerlink" href="#_CPPv39hal_timer" title="Permalink to this definition">?</a><br /></dt>
+<dd><em>#include &lt;hal_timer.h&gt;</em><p>The HAL timer structure. </p>
+<p>The user can declare as many of these structures as desired. They are enqueued on a particular HW timer queue when the user calls the :c:func:<code class="docutils literal notranslate"><a class="reference internal" href="#group___h_a_l_timer_1ga108e679ed0440ac830631fc662a04fa6"><span class="std std-ref"><span class="pre">hal_timer_start()</span></span></a></code> or :c:func:<code class="docutils literal notranslate"><a class="reference internal" href="#group___h_a_l_timer_1ga7cfacab8052286bcb9ebcf09fe4ba842"><span class="std std-ref"><span class="pre">hal_timer_start_at()</span></span></a></code> API. The user must have called :c:func:<code class="docutils literal notranslate"><a class="reference internal" href="#group___h_a_l_timer_1ga565e77630c3548207bb1cde8545230fd"><span class="std std-ref"><span class="pre">hal_timer_set_cb()</span></span></a></code> before starting a timer.</p>
+<p>NOTE: the user should not have to modify/examine the contents of this structure; the hal timer API should be used. </p>
+<div class="breathe-sectiondef docutils container">
+<p class="breathe-sectiondef-title rubric">Public Members</p>
+<dl class="variable">
+<dt id="c.hal_timer::bsp_timer">
+<span class="target" id="structhal__timer_1a6d7bba13d02c0192adb00dee4588216b"></span>void* <code class="descname">bsp_timer</code><a class="headerlink" href="#c.hal_timer::bsp_timer" title="Permalink to this definition">?</a></dt>
+<dd><p>Internal platform specific pointer. </p>
+</dd></dl>
+
+<dl class="variable">
+<dt id="c.hal_timer::cb_func">
+<span class="target" id="structhal__timer_1aa6b82b412ede70f5c580e20e5eb99aee"></span><a class="reference internal" href="#c.hal_timer_cb" title="hal_timer_cb">hal_timer_cb</a> <code class="descname">cb_func</code><a class="headerlink" href="#c.hal_timer::cb_func" title="Permalink to this definition">?</a></dt>
+<dd><p>Callback function. </p>
+</dd></dl>
+
+<dl class="variable">
+<dt id="c.hal_timer::cb_arg">
+<span class="target" id="structhal__timer_1a315d7a2737f930cb664b21deb0886a3c"></span>void* <code class="descname">cb_arg</code><a class="headerlink" href="#c.hal_timer::cb_arg" title="Permalink to this definition">?</a></dt>
+<dd><p>Callback argument. </p>
+</dd></dl>
+
+<dl class="variable">
+<dt id="c.hal_timer::expiry">
+<span class="target" id="structhal__timer_1ab4edba6c830706a49097ffe86a8d73d9"></span>uint32_t <code class="descname">expiry</code><a class="headerlink" href="#c.hal_timer::expiry" title="Permalink to this definition">?</a></dt>
+<dd><p>Tick at which timer should expire. </p>
+</dd></dl>
+
 </div>
-<div class="section" id="examples">
-<h2>Examples<a class="headerlink" href="#examples" title="Permalink to this headline">?</a></h2>
+</dd></dl>
+
 </div>
 </div>
 
@@ -285,6 +512,15 @@ <h2>Examples<a class="headerlink" href="#examples" title="Permalink to this head
                    </div>
                   </div>
                   
+    <div class="rst-footer-buttons row" role="navigation" aria-label="footer navigation">
+      
+        <a href="../hal_gpio/hal_gpio.html" class="btn btn-neutral float-right" title="GPIO" accesskey="n">Next: GPIO <span class="fa fa-arrow-circle-right"></span></a>
+      
+      
+        <a href="../hal.html" class="btn btn-neutral" title="Hardware Abstraction Layer" accesskey="p"><span class="fa fa-arrow-circle-left"></span> Previous: Hardware Abstraction Layer</a>
+      
+    </div>
+
                 </div>
               </div>
             </div>
diff --git a/develop/os/modules/hal/hal_uart/hal_uart.html b/develop/os/modules/hal/hal_uart/hal_uart.html
index d320a4824..723b16bb3 100644
--- a/develop/os/modules/hal/hal_uart/hal_uart.html
+++ b/develop/os/modules/hal/hal_uart/hal_uart.html
@@ -10,7 +10,7 @@
     
 
     
-    <title>hal_uart &mdash; Apache Mynewt 1.3.0 documentation</title>
+    <title>UART &mdash; Apache Mynewt 1.3.0 documentation</title>
     
 
     
@@ -40,7 +40,10 @@
           <link rel="index" title="Index"
                 href="../../../../genindex.html"/>
           <link rel="search" title="Search" href="../../../../search.html"/>
-      <link rel="top" title="Apache Mynewt 1.3.0 documentation" href="../../../../index.html"/> 
+      <link rel="top" title="Apache Mynewt 1.3.0 documentation" href="../../../../index.html"/>
+          <link rel="up" title="Hardware Abstraction Layer" href="../hal.html"/>
+          <link rel="next" title="SPI" href="../hal_spi/hal_spi.html"/>
+          <link rel="prev" title="GPIO" href="../hal_gpio/hal_gpio.html"/> 
 
     
     <script src="../../../../_static/js/modernizr.min.js"></script>
@@ -151,7 +154,11 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
   <div class="container">
     <a href="/documentation/">Docs</a> /
     
-    hal_uart
+      <a href="../../../os_user_guide.html">OS User Guide</a> /
+    
+      <a href="../hal.html">Hardware Abstraction Layer</a> /
+    
+    UART
     
   <div class="sourcelink">
     <a href="https://github.com/apache/mynewt-core/edit/master/docs/os/modules/hal/hal_uart/hal_uart.rst" class="icon icon-github"
@@ -211,12 +218,29 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
       
         
         
-            <ul>
+            <ul class="current">
 <li class="toctree-l1"><a class="reference internal" href="../../../../index.html">Introduction</a></li>
 <li class="toctree-l1"><a class="reference internal" href="../../../../get_started/index.html">Setup &amp; Get Started</a></li>
 <li class="toctree-l1"><a class="reference internal" href="../../../../concepts.html">Concepts</a></li>
 <li class="toctree-l1"><a class="reference internal" href="../../../../tutorials/tutorials.html">Tutorials</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../../os_user_guide.html">OS User Guide</a></li>
+<li class="toctree-l1 current"><a class="reference internal" href="../../../os_user_guide.html">OS User Guide</a><ul class="current">
+<li class="toctree-l2"><a class="reference internal" href="../../../core_os/mynewt_os.html">Kernel</a></li>
+<li class="toctree-l2 current"><a class="reference internal" href="../hal.html">Hardware Abstraction</a><ul class="current">
+<li class="toctree-l3"><a class="reference internal" href="../hal_timer/hal_timer.html">Timer</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../hal_gpio/hal_gpio.html">GPIO</a></li>
+<li class="toctree-l3 current"><a class="current reference internal" href="#">UART</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../hal_spi/hal_spi.html">SPI</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../hal_i2c/hal_i2c.html">I2C</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../hal_flash/hal_flash.html">Flash</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../hal_watchdog/hal_watchdog.html">Watchdog</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../hal_bsp/hal_bsp.html">BSP</a></li>
+</ul>
+</li>
+<li class="toctree-l2"><a class="reference internal" href="../../../core_os/porting/port_os.html">Porting Guide</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../../sysinitconfig/sysinitconfig.html">System Configuration</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../../console/console.html">Console</a></li>
+</ul>
+</li>
 <li class="toctree-l1"><a class="reference internal" href="../../../../network/ble/ble_intro.html">BLE User Guide</a></li>
 <li class="toctree-l1"><a class="reference internal" href="../../../../newt/index.html">Newt Tool Guide</a></li>
 <li class="toctree-l1"><a class="reference internal" href="../../../../newtmgr/index.html">Newt Manager Guide</a></li>
@@ -248,8 +272,8 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
                   <div role="main" class="document" itemscope="itemscope" itemtype="http://schema.org/Article">
                    <div itemprop="articleBody">
                     
-  <div class="section" id="hal-uart">
-<h1>hal_uart<a class="headerlink" href="#hal-uart" title="Permalink to this headline">?</a></h1>
+  <div class="section" id="uart">
+<h1>UART<a class="headerlink" href="#uart" title="Permalink to this headline">?</a></h1>
 <p>The hardware independent UART interface for Mynewt.</p>
 <div class="section" id="description">
 <h2>Description<a class="headerlink" href="#description" title="Permalink to this headline">?</a></h2>
@@ -258,10 +282,6 @@ <h2>Description<a class="headerlink" href="#description" title="Permalink to thi
 to apply settings such as speed, parity etc. to the UART. The UART port
 should be closed before any reconfiguring.</p>
 </div>
-<div class="section" id="definition">
-<h2>Definition<a class="headerlink" href="#definition" title="Permalink to this headline">?</a></h2>
-<p><a class="reference external" href="https://github.com/apache/incubator-mynewt-core/blob/master/hw/hal/include/hal/hal_uart.h">hal_uart.h</a></p>
-</div>
 <div class="section" id="examples">
 <h2>Examples<a class="headerlink" href="#examples" title="Permalink to this headline">?</a></h2>
 <p>This example shows a user writing a character to the uart in blocking
@@ -278,6 +298,178 @@ <h2>Examples<a class="headerlink" href="#examples" title="Permalink to this head
 <span class="go">}</span>
 </pre></div>
 </div>
+</div>
+<div class="section" id="api">
+<h2>API<a class="headerlink" href="#api" title="Permalink to this headline">?</a></h2>
+<dl class="enum">
+<dt id="c.HALUart::hal_uart_parity">
+<span class="target" id="group___h_a_l_uart_1ga54a2cb674e61c87d0659a9ee68b79046"></span><em class="property">enum </em><code class="descclassname">HALUart::</code><code class="descname">hal_uart_parity</code><a class="headerlink" href="#c.HALUart::hal_uart_parity" title="Permalink to this definition">?</a></dt>
+<dd><p><em>Values:</em></p>
+<dl class="enumvalue">
+<dt id="c.HALUart::HAL_UART_PARITY_NONE">
+<span class="target" id="group___h_a_l_uart_1gga54a2cb674e61c87d0659a9ee68b79046a04bc6026ce33740e3290bf2489a1ab66"></span><code class="descname">HAL_UART_PARITY_NONE</code> = 0<a class="headerlink" href="#c.HALUart::HAL_UART_PARITY_NONE" title="Permalink to this definition">?</a></dt>
+<dd><p>No Parity. </p>
+</dd></dl>
+
+<dl class="enumvalue">
+<dt id="c.HALUart::HAL_UART_PARITY_ODD">
+<span class="target" id="group___h_a_l_uart_1gga54a2cb674e61c87d0659a9ee68b79046a1ad3c3f7814a00e6b5bf06dbd5c03923"></span><code class="descname">HAL_UART_PARITY_ODD</code> = 1<a class="headerlink" href="#c.HALUart::HAL_UART_PARITY_ODD" title="Permalink to this definition">?</a></dt>
+<dd><p>Odd parity. </p>
+</dd></dl>
+
+<dl class="enumvalue">
+<dt id="c.HALUart::HAL_UART_PARITY_EVEN">
+<span class="target" id="group___h_a_l_uart_1gga54a2cb674e61c87d0659a9ee68b79046afe68bdf645970e0e83dca876087fa973"></span><code class="descname">HAL_UART_PARITY_EVEN</code> = 2<a class="headerlink" href="#c.HALUart::HAL_UART_PARITY_EVEN" title="Permalink to this definition">?</a></dt>
+<dd><p>Even parity. </p>
+</dd></dl>
+
+</dd></dl>
+
+<dl class="enum">
+<dt id="c.HALUart::hal_uart_flow_ctl">
+<span class="target" id="group___h_a_l_uart_1ga5aa2065acd6fab6c562b3e7f11799dd3"></span><em class="property">enum </em><code class="descclassname">HALUart::</code><code class="descname">hal_uart_flow_ctl</code><a class="headerlink" href="#c.HALUart::hal_uart_flow_ctl" title="Permalink to this definition">?</a></dt>
+<dd><p><em>Values:</em></p>
+<dl class="enumvalue">
+<dt id="c.HALUart::HAL_UART_FLOW_CTL_NONE">
+<span class="target" id="group___h_a_l_uart_1gga5aa2065acd6fab6c562b3e7f11799dd3a602a86e509c8edc7a400d47a7f19046f"></span><code class="descname">HAL_UART_FLOW_CTL_NONE</code> = 0<a class="headerlink" href="#c.HALUart::HAL_UART_FLOW_CTL_NONE" title="Permalink to this definition">?</a></dt>
+<dd><p>No Flow Control. </p>
+</dd></dl>
+
+<dl class="enumvalue">
+<dt id="c.HALUart::HAL_UART_FLOW_CTL_RTS_CTS">
+<span class="target" id="group___h_a_l_uart_1gga5aa2065acd6fab6c562b3e7f11799dd3aefef8f1847e02b9b414f26061bb29443"></span><code class="descname">HAL_UART_FLOW_CTL_RTS_CTS</code> = 1<a class="headerlink" href="#c.HALUart::HAL_UART_FLOW_CTL_RTS_CTS" title="Permalink to this definition">?</a></dt>
+<dd><p>RTS/CTS. </p>
+</dd></dl>
+
+</dd></dl>
+
+<dl class="typedef">
+<dt id="c.hal_uart_tx_char">
+<span class="target" id="group___h_a_l_uart_1ga048e6274132ffda2c1ba3fa97a967550"></span><em class="property">typedef </em>int<code class="descname">(* hal_uart_tx_char)</code><span class="sig-paren">(</span>void<em>&nbsp;*arg</em><span class="sig-paren">)</span><a class="headerlink" href="#c.hal_uart_tx_char" title="Permalink to this definition">?</a></dt>
+<dd><p>Function prototype for UART driver to ask for more data to send. </p>
+<p>Returns -1 if no more data is available for TX. Driver must call this with interrupts disabled. </p>
+</dd></dl>
+
+<dl class="typedef">
+<dt id="c.hal_uart_tx_done">
+<span class="target" id="group___h_a_l_uart_1ga465fd0514a4a013c4719edbecf7fad79"></span><em class="property">typedef </em>void<code class="descname">(* hal_uart_tx_done)</code><span class="sig-paren">(</span>void<em>&nbsp;*arg</em><span class="sig-paren">)</span><a class="headerlink" href="#c.hal_uart_tx_done" title="Permalink to this definition">?</a></dt>
+<dd><p>Function prototype for UART driver to report that transmission is complete. </p>
+<p>This should be called when transmission of last byte is finished. Driver must call this with interrupts disabled. </p>
+</dd></dl>
+
+<dl class="typedef">
+<dt id="c.hal_uart_rx_char">
+<span class="target" id="group___h_a_l_uart_1ga584da9fb7bd0c337f05b45ec958cf3e9"></span><em class="property">typedef </em>int<code class="descname">(* hal_uart_rx_char)</code><span class="sig-paren">(</span>void<em>&nbsp;*arg</em>, uint8_t<em>&nbsp;byte</em><span class="sig-paren">)</span><a class="headerlink" href="#c.hal_uart_rx_char" title="Permalink to this definition">?</a></dt>
+<dd><p>Function prototype for UART driver to report incoming byte of data. </p>
+<p>Returns -1 if data was dropped. Driver must call this with interrupts disabled. </p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.hal_uart_init_cbs">
+<span class="target" id="group___h_a_l_uart_1gaed951e1b190b127ea41f7a0081c2fc91"></span>int <code class="descname">hal_uart_init_cbs</code><span class="sig-paren">(</span>int<em>&nbsp;uart</em>, <a class="reference internal" href="#c.hal_uart_tx_char" title="hal_uart_tx_char">hal_uart_tx_char</a><em>&nbsp;tx_func</em>, <a class="reference internal" href="#c.hal_uart_tx_done" title="hal_uart_tx_done">hal_uart_tx_done</a><em>&nbsp;tx_done</em>, <a class="reference internal" href="#c.hal_uart_rx_char" title="hal_uart_rx_char">hal_uart_rx_char</a><em>&nbsp;rx_func</em>, void *<em>&nbsp;arg</em><span class="sig-paren">)</span><a class="headerlink" href="#c.hal_uart_init_cbs" title="Permalink to this definition">?</a></dt>
+<dd><p>Initializes given uart. </p>
+<p>Mapping of logical UART number to physical UART/GPIO pins is in BSP. </p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.hal_uart_init">
+<span class="target" id="group___h_a_l_uart_1ga1c1c1fe6f1a391601028864ecbf82dad"></span>int <code class="descname">hal_uart_init</code><span class="sig-paren">(</span>int<em>&nbsp;uart</em>, void *<em>&nbsp;cfg</em><span class="sig-paren">)</span><a class="headerlink" href="#c.hal_uart_init" title="Permalink to this definition">?</a></dt>
+<dd><p>Initialize the HAL uart. </p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>0 on success, non-zero error code on failure </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">uart</span></code>: The uart number to configure </li>
+<li><code class="docutils literal notranslate"><span class="pre">cfg</span></code>: Hardware specific uart configuration. This is passed from BSP directly to the MCU specific driver.</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.hal_uart_config">
+<span class="target" id="group___h_a_l_uart_1ga26356de3e25529e34b2f13a400476839"></span>int <code class="descname">hal_uart_config</code><span class="sig-paren">(</span>int<em>&nbsp;uart</em>, int32_t<em>&nbsp;speed</em>, uint8_t<em>&nbsp;databits</em>, uint8_t<em>&nbsp;stopbits</em>, enum  hal_uart_parity<em>&nbsp;parity</em>, enum  hal_uart_flow_ctl<em>&nbsp;flow_ctl</em><span class="sig-paren">)</span><a class="headerlink" href="#c.hal_uart_config" title="Permalink to this definition">?</a></dt>
+<dd><p>Applies given configuration to UART. </p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>0 on success, non-zero error code on failure </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">uart</span></code>: The UART number to configure </li>
+<li><code class="docutils literal notranslate"><span class="pre">speed</span></code>: The baudrate in bps to configure </li>
+<li><code class="docutils literal notranslate"><span class="pre">databits</span></code>: The number of databits to send per byte </li>
+<li><code class="docutils literal notranslate"><span class="pre">stopbits</span></code>: The number of stop bits to send </li>
+<li><code class="docutils literal notranslate"><span class="pre">parity</span></code>: The UART parity </li>
+<li><code class="docutils literal notranslate"><span class="pre">flow_ctl</span></code>: Flow control settings on the UART</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.hal_uart_close">
+<span class="target" id="group___h_a_l_uart_1ga809e353287e60b88ed9d6e87bd96d4af"></span>int <code class="descname">hal_uart_close</code><span class="sig-paren">(</span>int<em>&nbsp;uart</em><span class="sig-paren">)</span><a class="headerlink" href="#c.hal_uart_close" title="Permalink to this definition">?</a></dt>
+<dd><p>Close UART port. </p>
+<p>Can call <a class="reference internal" href="#group___h_a_l_uart_1ga26356de3e25529e34b2f13a400476839"><span class="std std-ref">hal_uart_config()</span></a> with different settings after calling this.</p>
+<p><dl class="docutils">
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">uart</span></code>: The UART number to close </li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.hal_uart_start_tx">
+<span class="target" id="group___h_a_l_uart_1gad30876672c3a563654b2fa8d5030e418"></span>void <code class="descname">hal_uart_start_tx</code><span class="sig-paren">(</span>int<em>&nbsp;uart</em><span class="sig-paren">)</span><a class="headerlink" href="#c.hal_uart_start_tx" title="Permalink to this definition">?</a></dt>
+<dd><p>More data queued for transmission. </p>
+<p>UART driver will start asking for that data.</p>
+<p><dl class="docutils">
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">uart</span></code>: The UART number to start TX on </li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.hal_uart_start_rx">
+<span class="target" id="group___h_a_l_uart_1ga758ae010736ef0fb2cfcc096ab22a707"></span>void <code class="descname">hal_uart_start_rx</code><span class="sig-paren">(</span>int<em>&nbsp;uart</em><span class="sig-paren">)</span><a class="headerlink" href="#c.hal_uart_start_rx" title="Permalink to this definition">?</a></dt>
+<dd><p>Upper layers have consumed some data, and are now ready to receive more. </p>
+<p>This is meaningful after uart_rx_char callback has returned -1 telling that no more data can be accepted.</p>
+<p><dl class="docutils">
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">uart</span></code>: The UART number to begin RX on </li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.hal_uart_blocking_tx">
+<span class="target" id="group___h_a_l_uart_1ga5b2feb681598e2151481e24f8115f913"></span>void <code class="descname">hal_uart_blocking_tx</code><span class="sig-paren">(</span>int<em>&nbsp;uart</em>, uint8_t<em>&nbsp;byte</em><span class="sig-paren">)</span><a class="headerlink" href="#c.hal_uart_blocking_tx" title="Permalink to this definition">?</a></dt>
+<dd><p>This is type of write where UART has to block until character has been sent. </p>
+<p>Used when printing diag output from system crash. Must be called with interrupts disabled.</p>
+<p><dl class="docutils">
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">uart</span></code>: The UART number to TX on </li>
+<li><code class="docutils literal notranslate"><span class="pre">byte</span></code>: The byte to TX on the UART </li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
 </div>
 </div>
 
@@ -285,6 +477,15 @@ <h2>Examples<a class="headerlink" href="#examples" title="Permalink to this head
                    </div>
                   </div>
                   
+    <div class="rst-footer-buttons row" role="navigation" aria-label="footer navigation">
+      
+        <a href="../hal_spi/hal_spi.html" class="btn btn-neutral float-right" title="SPI" accesskey="n">Next: SPI <span class="fa fa-arrow-circle-right"></span></a>
+      
+      
+        <a href="../hal_gpio/hal_gpio.html" class="btn btn-neutral" title="GPIO" accesskey="p"><span class="fa fa-arrow-circle-left"></span> Previous: GPIO</a>
+      
+    </div>
+
                 </div>
               </div>
             </div>
diff --git a/develop/os/modules/hal/hal_watchdog/hal_watchdog.html b/develop/os/modules/hal/hal_watchdog/hal_watchdog.html
index 3f38bb82f..15723b5a2 100644
--- a/develop/os/modules/hal/hal_watchdog/hal_watchdog.html
+++ b/develop/os/modules/hal/hal_watchdog/hal_watchdog.html
@@ -10,7 +10,7 @@
     
 
     
-    <title>hal_watchdog &mdash; Apache Mynewt 1.3.0 documentation</title>
+    <title>Watchdog &mdash; Apache Mynewt 1.3.0 documentation</title>
     
 
     
@@ -40,7 +40,10 @@
           <link rel="index" title="Index"
                 href="../../../../genindex.html"/>
           <link rel="search" title="Search" href="../../../../search.html"/>
-      <link rel="top" title="Apache Mynewt 1.3.0 documentation" href="../../../../index.html"/> 
+      <link rel="top" title="Apache Mynewt 1.3.0 documentation" href="../../../../index.html"/>
+          <link rel="up" title="Hardware Abstraction Layer" href="../hal.html"/>
+          <link rel="next" title="BSP" href="../hal_bsp/hal_bsp.html"/>
+          <link rel="prev" title="Flash" href="../hal_flash/hal_flash.html"/> 
 
     
     <script src="../../../../_static/js/modernizr.min.js"></script>
@@ -151,7 +154,11 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
   <div class="container">
     <a href="/documentation/">Docs</a> /
     
-    hal_watchdog
+      <a href="../../../os_user_guide.html">OS User Guide</a> /
+    
+      <a href="../hal.html">Hardware Abstraction Layer</a> /
+    
+    Watchdog
     
   <div class="sourcelink">
     <a href="https://github.com/apache/mynewt-core/edit/master/docs/os/modules/hal/hal_watchdog/hal_watchdog.rst" class="icon icon-github"
@@ -211,12 +218,29 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
       
         
         
-            <ul>
+            <ul class="current">
 <li class="toctree-l1"><a class="reference internal" href="../../../../index.html">Introduction</a></li>
 <li class="toctree-l1"><a class="reference internal" href="../../../../get_started/index.html">Setup &amp; Get Started</a></li>
 <li class="toctree-l1"><a class="reference internal" href="../../../../concepts.html">Concepts</a></li>
 <li class="toctree-l1"><a class="reference internal" href="../../../../tutorials/tutorials.html">Tutorials</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../../os_user_guide.html">OS User Guide</a></li>
+<li class="toctree-l1 current"><a class="reference internal" href="../../../os_user_guide.html">OS User Guide</a><ul class="current">
+<li class="toctree-l2"><a class="reference internal" href="../../../core_os/mynewt_os.html">Kernel</a></li>
+<li class="toctree-l2 current"><a class="reference internal" href="../hal.html">Hardware Abstraction</a><ul class="current">
+<li class="toctree-l3"><a class="reference internal" href="../hal_timer/hal_timer.html">Timer</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../hal_gpio/hal_gpio.html">GPIO</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../hal_uart/hal_uart.html">UART</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../hal_spi/hal_spi.html">SPI</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../hal_i2c/hal_i2c.html">I2C</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../hal_flash/hal_flash.html">Flash</a></li>
+<li class="toctree-l3 current"><a class="current reference internal" href="#">Watchdog</a></li>
+<li class="toctree-l3"><a class="reference internal" href="../hal_bsp/hal_bsp.html">BSP</a></li>
+</ul>
+</li>
+<li class="toctree-l2"><a class="reference internal" href="../../../core_os/porting/port_os.html">Porting Guide</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../../sysinitconfig/sysinitconfig.html">System Configuration</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../../console/console.html">Console</a></li>
+</ul>
+</li>
 <li class="toctree-l1"><a class="reference internal" href="../../../../network/ble/ble_intro.html">BLE User Guide</a></li>
 <li class="toctree-l1"><a class="reference internal" href="../../../../newt/index.html">Newt Tool Guide</a></li>
 <li class="toctree-l1"><a class="reference internal" href="../../../../newtmgr/index.html">Newt Manager Guide</a></li>
@@ -248,8 +272,8 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
                   <div role="main" class="document" itemscope="itemscope" itemtype="http://schema.org/Article">
                    <div itemprop="articleBody">
                     
-  <div class="section" id="hal-watchdog">
-<h1>hal_watchdog<a class="headerlink" href="#hal-watchdog" title="Permalink to this headline">?</a></h1>
+  <div class="section" id="watchdog">
+<h1>Watchdog<a class="headerlink" href="#watchdog" title="Permalink to this headline">?</a></h1>
 <p>The hardware independent interface to enable internal hardware
 watchdogs.</p>
 <div class="section" id="description">
@@ -263,16 +287,38 @@ <h2>Description<a class="headerlink" href="#description" title="Permalink to thi
 <code class="docutils literal notranslate"><span class="pre">hal_watchdog_enable()</span></code>. Watchdog should be tickled periodically with
 a frequency smaller than ?expire_secs? using <code class="docutils literal notranslate"><span class="pre">hal_watchdog_tickle()</span></code>.</p>
 </div>
-<div class="section" id="definition">
-<h2>Definition<a class="headerlink" href="#definition" title="Permalink to this headline">?</a></h2>
-<p><a class="reference external" href="https://github.com/apache/incubator-mynewt-core/blob/master/hw/hal/include/hal/hal_watchdog.h">hal_watchdog</a></p>
-</div>
-<div class="section" id="examples">
-<h2>Examples<a class="headerlink" href="#examples" title="Permalink to this headline">?</a></h2>
-<p>The OS initializes and starts a watchdog timer and tickles it
-periodically to check that the OS is running properly. This can be seen
-in
-<a class="reference external" href="https://github.com/apache/incubator-mynewt-core/blob/master/kernel/os/src/os.c">/kernel/os/src/os.c</a>.</p>
+<div class="section" id="api">
+<h2>API<a class="headerlink" href="#api" title="Permalink to this headline">?</a></h2>
+<dl class="function">
+<dt id="c.hal_watchdog_init">
+<span class="target" id="group___h_a_l_watchdog_1ga04a1971921c70c673e3deda826dac3ae"></span>int <code class="descname">hal_watchdog_init</code><span class="sig-paren">(</span>uint32_t<em>&nbsp;expire_msecs</em><span class="sig-paren">)</span><a class="headerlink" href="#c.hal_watchdog_init" title="Permalink to this definition">?</a></dt>
+<dd><p>Set a recurring watchdog timer to fire no sooner than in ?expire_secs? seconds. </p>
+<p>Watchdog should be tickled periodically with a frequency smaller than ?expire_secs?. Watchdog needs to be then started with a call to :c:func:<code class="docutils literal notranslate"><a class="reference internal" href="#group___h_a_l_watchdog_1gadeae985f016d5f9dbe463680b1e926b5"><span class="std std-ref"><span class="pre">hal_watchdog_enable()</span></span></a></code>.</p>
+<p><dl class="docutils">
+<dt><strong>Return</strong></dt>
+<dd>&lt; 0 on failure; on success return the actual expiration time as positive value </dd>
+<dt><strong>Parameters</strong></dt>
+<dd><ul class="breatheparameterlist first last simple">
+<li><code class="docutils literal notranslate"><span class="pre">expire_msecs</span></code>: Watchdog timer expiration time in msecs</li>
+</ul>
+</dd>
+</dl>
+</p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.hal_watchdog_enable">
+<span class="target" id="group___h_a_l_watchdog_1gadeae985f016d5f9dbe463680b1e926b5"></span>void <code class="descname">hal_watchdog_enable</code><span class="sig-paren">(</span>void<span class="sig-paren">)</span><a class="headerlink" href="#c.hal_watchdog_enable" title="Permalink to this definition">?</a></dt>
+<dd><p>Starts the watchdog. </p>
+</dd></dl>
+
+<dl class="function">
+<dt id="c.hal_watchdog_tickle">
+<span class="target" id="group___h_a_l_watchdog_1gaa06c7ed9a1b5526d22da255878533789"></span>void <code class="descname">hal_watchdog_tickle</code><span class="sig-paren">(</span>void<span class="sig-paren">)</span><a class="headerlink" href="#c.hal_watchdog_tickle" title="Permalink to this definition">?</a></dt>
+<dd><p>Tickles the watchdog. </p>
+<p>This needs to be done periodically, before the value configured in :c:func:<code class="docutils literal notranslate"><a class="reference internal" href="#group___h_a_l_watchdog_1ga04a1971921c70c673e3deda826dac3ae"><span class="std std-ref"><span class="pre">hal_watchdog_init()</span></span></a></code> expires. </p>
+</dd></dl>
+
 </div>
 </div>
 
@@ -280,6 +326,15 @@ <h2>Examples<a class="headerlink" href="#examples" title="Permalink to this head
                    </div>
                   </div>
                   
+    <div class="rst-footer-buttons row" role="navigation" aria-label="footer navigation">
+      
+        <a href="../hal_bsp/hal_bsp.html" class="btn btn-neutral float-right" title="BSP" accesskey="n">Next: BSP <span class="fa fa-arrow-circle-right"></span></a>
+      
+      
+        <a href="../hal_flash/hal_flash.html" class="btn btn-neutral" title="Flash" accesskey="p"><span class="fa fa-arrow-circle-left"></span> Previous: Flash</a>
+      
+    </div>
+
                 </div>
               </div>
             </div>
diff --git a/develop/os/modules/sysinitconfig/sysconfig_error.html b/develop/os/modules/sysinitconfig/sysconfig_error.html
index d3ba771e4..0a14a3422 100644
--- a/develop/os/modules/sysinitconfig/sysconfig_error.html
+++ b/develop/os/modules/sysinitconfig/sysconfig_error.html
@@ -42,7 +42,7 @@
           <link rel="search" title="Search" href="../../../search.html"/>
       <link rel="top" title="Apache Mynewt 1.3.0 documentation" href="../../../index.html"/>
           <link rel="up" title="System Configuration and Initialization" href="sysinitconfig.html"/>
-          <link rel="next" title="BLE User Guide" href="../../../network/ble/ble_intro.html"/>
+          <link rel="next" title="Console" href="../console/console.html"/>
           <link rel="prev" title="System Configuration and Initialization" href="sysinitconfig.html"/> 
 
     
@@ -224,13 +224,14 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
 <li class="toctree-l1"><a class="reference internal" href="../../../concepts.html">Concepts</a></li>
 <li class="toctree-l1"><a class="reference internal" href="../../../tutorials/tutorials.html">Tutorials</a></li>
 <li class="toctree-l1 current"><a class="reference internal" href="../../os_user_guide.html">OS User Guide</a><ul class="current">
-<li class="toctree-l2"><a class="reference internal" href="../../core_os/mynewt_os.html">OS Core</a></li>
-<li class="toctree-l2"><a class="reference internal" href="../../core_os/porting/port_os.html">Porting Mynewt OS</a></li>
-<li class="toctree-l2"><a class="reference internal" href="../console/console.html">Console</a></li>
-<li class="toctree-l2 current"><a class="reference internal" href="sysinitconfig.html">System Configuration and Initialization</a><ul class="current">
+<li class="toctree-l2"><a class="reference internal" href="../../core_os/mynewt_os.html">Kernel</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../hal/hal.html">Hardware Abstraction</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../../core_os/porting/port_os.html">Porting Guide</a></li>
+<li class="toctree-l2 current"><a class="reference internal" href="sysinitconfig.html">System Configuration</a><ul class="current">
 <li class="toctree-l3 current"><a class="current reference internal" href="#">Validation and Error Messages</a></li>
 </ul>
 </li>
+<li class="toctree-l2"><a class="reference internal" href="../console/console.html">Console</a></li>
 </ul>
 </li>
 <li class="toctree-l1"><a class="reference internal" href="../../../network/ble/ble_intro.html">BLE User Guide</a></li>
@@ -715,7 +716,7 @@ <h3><a class="toc-backref" href="#id16">BSP Package Overrides Undefined Configur
                   
     <div class="rst-footer-buttons row" role="navigation" aria-label="footer navigation">
       
-        <a href="../../../network/ble/ble_intro.html" class="btn btn-neutral float-right" title="BLE User Guide" accesskey="n">Next: BLE User Guide <span class="fa fa-arrow-circle-right"></span></a>
+        <a href="../console/console.html" class="btn btn-neutral float-right" title="Console" accesskey="n">Next: Console <span class="fa fa-arrow-circle-right"></span></a>
       
       
         <a href="sysinitconfig.html" class="btn btn-neutral" title="System Configuration and Initialization" accesskey="p"><span class="fa fa-arrow-circle-left"></span> Previous: System Configuration and Initialization</a>
diff --git a/develop/os/modules/sysinitconfig/sysinitconfig.html b/develop/os/modules/sysinitconfig/sysinitconfig.html
index c26bc01e9..15afca30c 100644
--- a/develop/os/modules/sysinitconfig/sysinitconfig.html
+++ b/develop/os/modules/sysinitconfig/sysinitconfig.html
@@ -43,7 +43,7 @@
       <link rel="top" title="Apache Mynewt 1.3.0 documentation" href="../../../index.html"/>
           <link rel="up" title="OS User Guide" href="../../os_user_guide.html"/>
           <link rel="next" title="Validation and Error Messages" href="sysconfig_error.html"/>
-          <link rel="prev" title="Console" href="../console/console.html"/> 
+          <link rel="prev" title="Porting Mynewt to a new CPU Architecture" href="../../core_os/porting/port_cpu.html"/> 
 
     
     <script src="../../../_static/js/modernizr.min.js"></script>
@@ -222,13 +222,14 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
 <li class="toctree-l1"><a class="reference internal" href="../../../concepts.html">Concepts</a></li>
 <li class="toctree-l1"><a class="reference internal" href="../../../tutorials/tutorials.html">Tutorials</a></li>
 <li class="toctree-l1 current"><a class="reference internal" href="../../os_user_guide.html">OS User Guide</a><ul class="current">
-<li class="toctree-l2"><a class="reference internal" href="../../core_os/mynewt_os.html">OS Core</a></li>
-<li class="toctree-l2"><a class="reference internal" href="../../core_os/porting/port_os.html">Porting Mynewt OS</a></li>
-<li class="toctree-l2"><a class="reference internal" href="../console/console.html">Console</a></li>
-<li class="toctree-l2 current"><a class="current reference internal" href="#">System Configuration and Initialization</a><ul>
+<li class="toctree-l2"><a class="reference internal" href="../../core_os/mynewt_os.html">Kernel</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../hal/hal.html">Hardware Abstraction</a></li>
+<li class="toctree-l2"><a class="reference internal" href="../../core_os/porting/port_os.html">Porting Guide</a></li>
+<li class="toctree-l2 current"><a class="current reference internal" href="#">System Configuration</a><ul>
 <li class="toctree-l3"><a class="reference internal" href="sysconfig_error.html">Validation and Error Messages</a></li>
 </ul>
 </li>
+<li class="toctree-l2"><a class="reference internal" href="../console/console.html">Console</a></li>
 </ul>
 </li>
 <li class="toctree-l1"><a class="reference internal" href="../../../network/ble/ble_intro.html">BLE User Guide</a></li>
@@ -931,7 +932,7 @@ <h2><a class="toc-backref" href="#id16">Conditional Configurations</a><a class="
         <a href="sysconfig_error.html" class="btn btn-neutral float-right" title="Validation and Error Messages" accesskey="n">Next: Validation and Error Messages <span class="fa fa-arrow-circle-right"></span></a>
       
       
-        <a href="../console/console.html" class="btn btn-neutral" title="Console" accesskey="p"><span class="fa fa-arrow-circle-left"></span> Previous: Console</a>
+        <a href="../../core_os/porting/port_cpu.html" class="btn btn-neutral" title="Porting Mynewt to a new CPU Architecture" accesskey="p"><span class="fa fa-arrow-circle-left"></span> Previous: Porting Mynewt to a new CPU Architecture</a>
       
     </div>
 
diff --git a/develop/os/os_user_guide.html b/develop/os/os_user_guide.html
index 21db61546..9eb384d07 100644
--- a/develop/os/os_user_guide.html
+++ b/develop/os/os_user_guide.html
@@ -41,7 +41,7 @@
                 href="../genindex.html"/>
           <link rel="search" title="Search" href="../search.html"/>
       <link rel="top" title="Apache Mynewt 1.3.0 documentation" href="../index.html"/>
-          <link rel="next" title="Mynewt Core OS" href="core_os/mynewt_os.html"/>
+          <link rel="next" title="Apache Mynewt Operating System Kernel" href="core_os/mynewt_os.html"/>
           <link rel="prev" title="Enable Wi-Fi on Arduino MKR1000" href="../tutorials/other/wi-fi_on_arduino.html"/> 
 
     
@@ -219,10 +219,11 @@ <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (Dece
 <li class="toctree-l1"><a class="reference internal" href="../concepts.html">Concepts</a></li>
 <li class="toctree-l1"><a class="reference internal" href="../tutorials/tutorials.html">Tutorials</a></li>
 <li class="toctree-l1 current"><a class="current reference internal" href="#">OS User Guide</a><ul>
-<li class="toctree-l2"><a class="reference internal" href="core_os/mynewt_os.html">OS Core</a></li>
-<li class="toctree-l2"><a class="reference internal" href="core_os/porting/port_os.html">Porting Mynewt OS</a></li>
+<li class="toctree-l2"><a class="reference internal" href="core_os/mynewt_os.html">Kernel</a></li>
+<li class="toctree-l2"><a class="reference internal" href="modules/hal/hal.html">Hardware Abstraction</a></li>
+<li class="toctree-l2"><a class="reference internal" href="core_os/porting/port_os.html">Porting Guide</a></li>
+<li class="toctree-l2"><a class="reference internal" href="modules/sysinitconfig/sysinitconfig.html">System Configuration</a></li>
 <li class="toctree-l2"><a class="reference internal" href="modules/console/console.html">Console</a></li>
-<li class="toctree-l2"><a class="reference internal" href="modules/sysinitconfig/sysinitconfig.html">System Configuration and Initialization</a></li>
 </ul>
 </li>
 <li class="toctree-l1"><a class="reference internal" href="../network/ble/ble_intro.html">BLE User Guide</a></li>
@@ -280,7 +281,7 @@ <h1>OS User Guide<a class="headerlink" href="#os-user-guide" title="Permalink to
                   
     <div class="rst-footer-buttons row" role="navigation" aria-label="footer navigation">
       
-        <a href="core_os/mynewt_os.html" class="btn btn-neutral float-right" title="Mynewt Core OS" accesskey="n">Next: Mynewt Core OS <span class="fa fa-arrow-circle-right"></span></a>
+        <a href="core_os/mynewt_os.html" class="btn btn-neutral float-right" title="Apache Mynewt Operating System Kernel" accesskey="n">Next: Apache Mynewt Operating System Kernel <span class="fa fa-arrow-circle-right"></span></a>
       
       
         <a href="../tutorials/other/wi-fi_on_arduino.html" class="btn btn-neutral" title="Enable Wi-Fi on Arduino MKR1000" accesskey="p"><span class="fa fa-arrow-circle-left"></span> Previous: Enable Wi-Fi on Arduino MKR1000</a>
diff --git a/develop/os/tutorials/codesize.html b/develop/os/tutorials/codesize.html
deleted file mode 100644
index 3b49a784c..000000000
--- a/develop/os/tutorials/codesize.html
+++ /dev/null
@@ -1,363 +0,0 @@
-
-
-<!DOCTYPE html>
-<html lang="en">
-  <head>
-    <meta charset="utf-8">
-    <meta http-equiv="X-UA-Compatible" content="IE=edge">
-    <meta name="viewport" content="width=device-width, initial-scale=1.0">
-
-    
-
-    
-    <title>How to Reduce Application Code Size &mdash; Apache Mynewt 1.3.0 documentation</title>
-    
-
-    
-    
-      <link rel="shortcut icon" href="../../_static/mynewt-logo-only-newt32x32.png"/>
-    
-
-    
-
-    <link rel="stylesheet" href="../../_static/css/theme.css" type="text/css" />
-
-    
-      <link rel="stylesheet" href="../../_static/css/sphinx_theme.css" type="text/css" />
-    
-      <link rel="stylesheet" href="../../_static/css/bootstrap-3.0.3.min.css" type="text/css" />
-    
-      <link rel="stylesheet" href="../../_static/css/v2.css" type="text/css" />
-    
-      <link rel="stylesheet" href="../../_static/css/custom.css" type="text/css" />
-    
-      <link rel="stylesheet" href="../../_static/css/restructuredtext.css" type="text/css" />
-    
-
-    
-
-    <link rel="stylesheet" href="../../_static/css/overrides.css" type="text/css" />
-          <link rel="index" title="Index"
-                href="../../genindex.html"/>
-          <link rel="search" title="Search" href="../../search.html"/>
-      <link rel="top" title="Apache Mynewt 1.3.0 documentation" href="../../index.html"/> 
-
-    
-    <script src="../../_static/js/modernizr.min.js"></script>
-
-    
-    <script>
-    (function(i, s, o, g, r, a, m) {
-	i["GoogleAnalyticsObject"] = r;
-	(i[r] =
-		i[r] ||
-		function() {
-			(i[r].q = i[r].q || []).push(arguments);
-		}),
-		(i[r].l = 1 * new Date());
-	(a = s.createElement(o)), (m = s.getElementsByTagName(o)[0]);
-	a.async = 1;
-	a.src = g;
-	m.parentNode.insertBefore(a, m);
-})(window, document, "script", "//www.google-analytics.com/analytics.js", "ga");
-
-ga("create", "UA-72162311-1", "auto");
-ga("send", "pageview");
-</script>
-    
-
-  </head>
-
-  <body class="not-front page-documentation" role="document" >
-    <div id="wrapper">
-      <div class="container">
-    <div id="banner" class="row v2-main-banner">
-        <a class="logo-cell" href="/">
-            <img class="logo" src="../../_static/img/logo.png">
-        </a>
-        <div class="tagline-cell">
-            <h4 class="tagline">An OS to build, deploy and securely manage billions of devices</h4>
-        </div>
-        <div class="news-cell">
-            <div class="well">
-              <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (December 13, 2017)
-            </div>
-        </div>
-    </div>
-</div>
-      
-<header>
-    <nav id="navbar" class="navbar navbar-inverse" role="navigation">
-        <div class="container">
-            <!-- Collapsed navigation -->
-            <div class="navbar-header">
-                <!-- Expander button -->
-                <button type="button" class="navbar-toggle" data-toggle="collapse" data-target=".navbar-collapse">
-                    <span class="sr-only">Toggle navigation</span>
-                    <span class="icon-bar"></span>
-                    <span class="icon-bar"></span>
-                    <span class="icon-bar"></span>
-                </button>
-
-            </div>
-
-            <!-- Expanded navigation -->
-            <div class="navbar-collapse collapse">
-                <!-- Main navigation -->
-                <ul class="nav navbar-nav navbar-right">
-                    <li>
-                        <a href="/"><i class="fa fa-home" style="font-size: larger;"></i></a>
-                    </li>
-                    <li class="important">
-                        <a href="/get_started/quick_start.html">Quick Start</a>
-                    </li>
-                    <li>
-                        <a href="/about/">About</a>
-                    </li>
-                    <li>
-                        <a href="/talks/">Talks</a>
-                    </li>
-                    <li class="active">
-                        <a href="/documentation/">Documentation</a>
-                    </li>
-                    <li>
-                        <a href="/download/">Download</a>
-                    </li>
-                    <li>
-                        <a href="/community/">Community</a>
-                    </li>
-                    <li>
-                        <a href="/events/">Events</a>
-                    </li>
-                </ul>
-
-                <!-- Search, Navigation and Repo links -->
-                <ul class="nav navbar-nav navbar-right">
-                    
-                </ul>
-            </div>
-        </div>
-    </nav>
-</header>
-      <!-- STARTS MAIN CONTENT -->
-      <div id="main-content">
-        
-
-
-
-
-
-<div id="breadcrumb">
-  <div class="container">
-    <a href="/documentation/">Docs</a> /
-    
-    How to Reduce Application Code Size
-    
-  <div class="sourcelink">
-    <a href="https://github.com/apache/mynewt-core/edit/master/docs/os/tutorials/codesize.rst" class="icon icon-github"
-           rel="nofollow"> Edit on GitHub</a>
-</div>
-  </div>
-</div>
-        <!-- STARTS CONTAINER -->
-        <div class="container">
-          <!-- STARTS .content -->
-          <div id="content" class="row">
-            
-            <!-- STARTS .container-sidebar -->
-<div class="container-sidebar col-xs-12 col-sm-3">
-  <div id="docSidebar" class="sticky-container">
-    <div role="search" class="sphinx-search">
-  <form id="rtd-search-form" class="wy-form" action="../../search.html" method="get">
-    <input type="text" name="q" placeholder="Search documentation" class="search-documentation" />
-    <input type="hidden" name="check_keywords" value="yes" />
-    <input type="hidden" name="area" value="default" />
-  </form>
-</div>
-    
-<!-- Note: only works when deployed -->
-<select class="form-control" onchange="if (this.value) window.location.href=this.value">
-    <option
-      value="/develop"
-      selected
-      >
-      Version: develop (latest - mynewt-documentation)
-    </option>
-    <option
-      value="/latest/os/introduction"
-      >
-      Version: master (latest - mynewt-site)
-    </option>
-    <option
-      value="/v1_2_0/os/introduction"
-      >
-      Version: 1.2.0
-    </option>
-    <option
-      value="/v1_1_0/os/introduction">
-      Version: 1.1.0
-    </option>
-    <option
-      value="/v1_0_0/os/introduction">
-      Version: 1.0.0
-    </option>
-    <option
-      value="/v0_9_0/os/introduction">
-      Version: 0_9_0
-    </option>
-</select>
-    <div class="region region-sidebar">
-      <div class="docs-menu">
-      
-        
-        
-            <ul>
-<li class="toctree-l1"><a class="reference internal" href="../../index.html">Introduction</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../get_started/index.html">Setup &amp; Get Started</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../concepts.html">Concepts</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../tutorials/tutorials.html">Tutorials</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../os_user_guide.html">OS User Guide</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../network/ble/ble_intro.html">BLE User Guide</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../newt/index.html">Newt Tool Guide</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../newtmgr/index.html">Newt Manager Guide</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../misc/index.html">Appendix</a></li>
-</ul>
-
-        
-      
-      </div>
-    </div>
-  </div>
-  <!-- ENDS STICKY CONTAINER -->
-</div>
-<!-- ENDS .container-sidebar -->
-
-            <div class="col-xs-12 col-sm-9">
-              <div class="alert alert-info" role="alert">
-  <p>
-    This is the development version of Apache Mynewt documentation. As such it may not be as complete as the latest
-    stable version of the documentation found <a href="/latest/os/introduction/">here</a>.
-  </p>
-  <p>
-    To improve this documentation please visit <a href="https://github.com/apache/mynewt-documentation">https://github.com/apache/mynewt-documentation</a>.
-  </p>
-</div>
-              
-              <div class="">
-                <div class="rst-content">
-                  <div role="main" class="document" itemscope="itemscope" itemtype="http://schema.org/Article">
-                   <div itemprop="articleBody">
-                    
-  <div class="section" id="how-to-reduce-application-code-size">
-<h1>How to Reduce Application Code Size<a class="headerlink" href="#how-to-reduce-application-code-size" title="Permalink to this headline">?</a></h1>
-<p>Gettng your application to fit in an image slot can be challenging,
-particularly on flash constrained hardware such as the nRF51. Below are
-some suggested system configuration settings that reduce the code size
-of your Mynewt image.</p>
-<table border="1" class="docutils">
-<colgroup>
-<col width="35%" />
-<col width="65%" />
-</colgroup>
-<thead valign="bottom">
-<tr class="row-odd"><th class="head">Setting</th>
-<th class="head">Description</th>
-</tr>
-</thead>
-<tbody valign="top">
-<tr class="row-even"><td>LOG_LEVEL: 255</td>
-<td>Disable all logging.</td>
-</tr>
-<tr class="row-odd"><td>LOG_CLI: 0</td>
-<td>Disable log shell commands.</td>
-</tr>
-<tr class="row-even"><td>STATS_CLI: 0</td>
-<td>Disable stats shell commands.</td>
-</tr>
-<tr class="row-odd"><td>SHELL_TASK: 0</td>
-<td>Disable the interactive shell.</td>
-</tr>
-<tr class="row-even"><td>SHELL_OS_MODULE: 0</td>
-<td>Disable memory management shell commands.</td>
-</tr>
-<tr class="row-odd"><td>SHELL_CMD_HELP: 0</td>
-<td>Disable help for shell commands.</td>
-</tr>
-</tbody>
-</table>
-<p>You can use the <code class="docutils literal notranslate"><span class="pre">newt</span> <span class="pre">target</span> <span class="pre">set</span></code> command to set the syscfg settings
-in the <code class="docutils literal notranslate"><span class="pre">syscfg.yml</span></code> file for the target. See the <a class="reference external" href="/newt/command_list/newt_target">Newt Tool Command
-Guide</a> for the command syntax.</p>
-<p><strong>Note:</strong> The <code class="docutils literal notranslate"><span class="pre">newt</span> <span class="pre">target</span> <span class="pre">set</span></code> command deletes all the current syscfg
-settings in the target <code class="docutils literal notranslate"><span class="pre">syscfg.yml</span></code> file and only sets the syscfg
-settings specified in the command. If you are experimenting with
-different settings to see how they affect the code size and do not want
-to reenter all the setting values in the <code class="docutils literal notranslate"><span class="pre">newt</span> <span class="pre">target</span> <span class="pre">set</span></code> command,
-you can use the <code class="docutils literal notranslate"><span class="pre">newt</span> <span class="pre">target</span> <span class="pre">amend</span></code> command. This command adds or
-updates only the settings specified in the command and does not
-overwrite other setting values. While you can also edit the target
-<code class="docutils literal notranslate"><span class="pre">syscfg.yml</span></code> file directly, we recommend that you use the
-<code class="docutils literal notranslate"><span class="pre">newt</span> <span class="pre">target</span></code> commands.</p>
-</div>
-
-
-                   </div>
-                  </div>
-                  
-                </div>
-              </div>
-            </div>
-            <!-- ENDS CONTENT SECTION -->
-          </div>
-          <!-- ENDS .content -->
-        </div>
-      </div>
-      <footer>
-  <div class="container">
-    <div class="row">
-      <div class="col-xs-12">
-          
-              <p class="copyright">Apache Mynewt is available under Apache License, version 2.0.</p>
-          
-      </div>
-      <div class="col-xs-12">
-          <div class="logos">
-              <img src="../../_static/img/asf_logo_wide_small.png" alt="Apache" title="Apache">
-              <small class="footnote">
-                Apache Mynewt, Mynewt, Apache, the Apache feather logo, and the Apache Mynewt project logo are either
-                registered trademarks or trademarks of the Apache Software Foundation in the United States and other countries.
-              </small>
-              <a href="https://join.slack.com/mynewt/shared_invite/MTkwMTg1ODM1NTg5LTE0OTYxNzQ4NzQtZTU1YmNhYjhkMg">
-                <img src="../../_static/img/add_to_slack.png" alt="Slack Icon" title="Join our Slack Community" />
-              </a>
-          </div>
-      </div>
-    </div>
-  </div>
-</footer>
-    </div>
-    <!-- ENDS #wrapper -->
-
-  
-
-    <script type="text/javascript">
-        var DOCUMENTATION_OPTIONS = {
-            URL_ROOT:'../../',
-            VERSION:'1.3.0',
-            COLLAPSE_INDEX:false,
-            FILE_SUFFIX:'.html',
-            HAS_SOURCE:  true,
-            SOURCELINK_SUFFIX: '.txt'
-        };
-    </script>
-      <script type="text/javascript" src="../../_static/jquery.js"></script>
-      <script type="text/javascript" src="../../_static/underscore.js"></script>
-      <script type="text/javascript" src="../../_static/doctools.js"></script>
-      <script type="text/javascript" src="../../_static/js/bootstrap-3.0.3.min.js"></script>
-      <script type="text/javascript" src="../../_static/js/affix.js"></script>
-      <script type="text/javascript" src="../../_static/js/main.js"></script>
-
-   
-
-  </body>
-</html>
\ No newline at end of file
diff --git a/develop/os/tutorials/unit_test.html b/develop/os/tutorials/unit_test.html
deleted file mode 100644
index 7983089f5..000000000
--- a/develop/os/tutorials/unit_test.html
+++ /dev/null
@@ -1,629 +0,0 @@
-
-
-<!DOCTYPE html>
-<html lang="en">
-  <head>
-    <meta charset="utf-8">
-    <meta http-equiv="X-UA-Compatible" content="IE=edge">
-    <meta name="viewport" content="width=device-width, initial-scale=1.0">
-
-    
-
-    
-    <title>Write a Test Suite for a Package &mdash; Apache Mynewt 1.3.0 documentation</title>
-    
-
-    
-    
-      <link rel="shortcut icon" href="../../_static/mynewt-logo-only-newt32x32.png"/>
-    
-
-    
-
-    <link rel="stylesheet" href="../../_static/css/theme.css" type="text/css" />
-
-    
-      <link rel="stylesheet" href="../../_static/css/sphinx_theme.css" type="text/css" />
-    
-      <link rel="stylesheet" href="../../_static/css/bootstrap-3.0.3.min.css" type="text/css" />
-    
-      <link rel="stylesheet" href="../../_static/css/v2.css" type="text/css" />
-    
-      <link rel="stylesheet" href="../../_static/css/custom.css" type="text/css" />
-    
-      <link rel="stylesheet" href="../../_static/css/restructuredtext.css" type="text/css" />
-    
-
-    
-
-    <link rel="stylesheet" href="../../_static/css/overrides.css" type="text/css" />
-          <link rel="index" title="Index"
-                href="../../genindex.html"/>
-          <link rel="search" title="Search" href="../../search.html"/>
-      <link rel="top" title="Apache Mynewt 1.3.0 documentation" href="../../index.html"/> 
-
-    
-    <script src="../../_static/js/modernizr.min.js"></script>
-
-    
-    <script>
-    (function(i, s, o, g, r, a, m) {
-	i["GoogleAnalyticsObject"] = r;
-	(i[r] =
-		i[r] ||
-		function() {
-			(i[r].q = i[r].q || []).push(arguments);
-		}),
-		(i[r].l = 1 * new Date());
-	(a = s.createElement(o)), (m = s.getElementsByTagName(o)[0]);
-	a.async = 1;
-	a.src = g;
-	m.parentNode.insertBefore(a, m);
-})(window, document, "script", "//www.google-analytics.com/analytics.js", "ga");
-
-ga("create", "UA-72162311-1", "auto");
-ga("send", "pageview");
-</script>
-    
-
-  </head>
-
-  <body class="not-front page-documentation" role="document" >
-    <div id="wrapper">
-      <div class="container">
-    <div id="banner" class="row v2-main-banner">
-        <a class="logo-cell" href="/">
-            <img class="logo" src="../../_static/img/logo.png">
-        </a>
-        <div class="tagline-cell">
-            <h4 class="tagline">An OS to build, deploy and securely manage billions of devices</h4>
-        </div>
-        <div class="news-cell">
-            <div class="well">
-              <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (December 13, 2017)
-            </div>
-        </div>
-    </div>
-</div>
-      
-<header>
-    <nav id="navbar" class="navbar navbar-inverse" role="navigation">
-        <div class="container">
-            <!-- Collapsed navigation -->
-            <div class="navbar-header">
-                <!-- Expander button -->
-                <button type="button" class="navbar-toggle" data-toggle="collapse" data-target=".navbar-collapse">
-                    <span class="sr-only">Toggle navigation</span>
-                    <span class="icon-bar"></span>
-                    <span class="icon-bar"></span>
-                    <span class="icon-bar"></span>
-                </button>
-
-            </div>
-
-            <!-- Expanded navigation -->
-            <div class="navbar-collapse collapse">
-                <!-- Main navigation -->
-                <ul class="nav navbar-nav navbar-right">
-                    <li>
-                        <a href="/"><i class="fa fa-home" style="font-size: larger;"></i></a>
-                    </li>
-                    <li class="important">
-                        <a href="/get_started/quick_start.html">Quick Start</a>
-                    </li>
-                    <li>
-                        <a href="/about/">About</a>
-                    </li>
-                    <li>
-                        <a href="/talks/">Talks</a>
-                    </li>
-                    <li class="active">
-                        <a href="/documentation/">Documentation</a>
-                    </li>
-                    <li>
-                        <a href="/download/">Download</a>
-                    </li>
-                    <li>
-                        <a href="/community/">Community</a>
-                    </li>
-                    <li>
-                        <a href="/events/">Events</a>
-                    </li>
-                </ul>
-
-                <!-- Search, Navigation and Repo links -->
-                <ul class="nav navbar-nav navbar-right">
-                    
-                </ul>
-            </div>
-        </div>
-    </nav>
-</header>
-      <!-- STARTS MAIN CONTENT -->
-      <div id="main-content">
-        
-
-
-
-
-
-<div id="breadcrumb">
-  <div class="container">
-    <a href="/documentation/">Docs</a> /
-    
-    Write a Test Suite for a Package
-    
-  <div class="sourcelink">
-    <a href="https://github.com/apache/mynewt-core/edit/master/docs/os/tutorials/unit_test.rst" class="icon icon-github"
-           rel="nofollow"> Edit on GitHub</a>
-</div>
-  </div>
-</div>
-        <!-- STARTS CONTAINER -->
-        <div class="container">
-          <!-- STARTS .content -->
-          <div id="content" class="row">
-            
-            <!-- STARTS .container-sidebar -->
-<div class="container-sidebar col-xs-12 col-sm-3">
-  <div id="docSidebar" class="sticky-container">
-    <div role="search" class="sphinx-search">
-  <form id="rtd-search-form" class="wy-form" action="../../search.html" method="get">
-    <input type="text" name="q" placeholder="Search documentation" class="search-documentation" />
-    <input type="hidden" name="check_keywords" value="yes" />
-    <input type="hidden" name="area" value="default" />
-  </form>
-</div>
-    
-<!-- Note: only works when deployed -->
-<select class="form-control" onchange="if (this.value) window.location.href=this.value">
-    <option
-      value="/develop"
-      selected
-      >
-      Version: develop (latest - mynewt-documentation)
-    </option>
-    <option
-      value="/latest/os/introduction"
-      >
-      Version: master (latest - mynewt-site)
-    </option>
-    <option
-      value="/v1_2_0/os/introduction"
-      >
-      Version: 1.2.0
-    </option>
-    <option
-      value="/v1_1_0/os/introduction">
-      Version: 1.1.0
-    </option>
-    <option
-      value="/v1_0_0/os/introduction">
-      Version: 1.0.0
-    </option>
-    <option
-      value="/v0_9_0/os/introduction">
-      Version: 0_9_0
-    </option>
-</select>
-    <div class="region region-sidebar">
-      <div class="docs-menu">
-      
-        
-        
-            <ul>
-<li class="toctree-l1"><a class="reference internal" href="../../index.html">Introduction</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../get_started/index.html">Setup &amp; Get Started</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../concepts.html">Concepts</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../tutorials/tutorials.html">Tutorials</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../os_user_guide.html">OS User Guide</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../network/ble/ble_intro.html">BLE User Guide</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../newt/index.html">Newt Tool Guide</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../newtmgr/index.html">Newt Manager Guide</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../misc/index.html">Appendix</a></li>
-</ul>
-
-        
-      
-      </div>
-    </div>
-  </div>
-  <!-- ENDS STICKY CONTAINER -->
-</div>
-<!-- ENDS .container-sidebar -->
-
-            <div class="col-xs-12 col-sm-9">
-              <div class="alert alert-info" role="alert">
-  <p>
-    This is the development version of Apache Mynewt documentation. As such it may not be as complete as the latest
-    stable version of the documentation found <a href="/latest/os/introduction/">here</a>.
-  </p>
-  <p>
-    To improve this documentation please visit <a href="https://github.com/apache/mynewt-documentation">https://github.com/apache/mynewt-documentation</a>.
-  </p>
-</div>
-              
-              <div class="">
-                <div class="rst-content">
-                  <div role="main" class="document" itemscope="itemscope" itemtype="http://schema.org/Article">
-                   <div itemprop="articleBody">
-                    
-  <div class="section" id="write-a-test-suite-for-a-package">
-<h1>Write a Test Suite for a Package<a class="headerlink" href="#write-a-test-suite-for-a-package" title="Permalink to this headline">?</a></h1>
-<p>This document guides the reader through creating a test suite for a
-Mynewt package.</p>
-<div class="section" id="introduction">
-<h2>Introduction<a class="headerlink" href="#introduction" title="Permalink to this headline">?</a></h2>
-<p>Writing a test suite involves using the
-<code class="docutils literal notranslate"><span class="pre">`test/testutil</span></code> &lt;../modules/testutil/testutil.html&gt;`__ package. The
-testutil library provides the functionality needed to define test suites
-and test cases.</p>
-</div>
-<div class="section" id="choose-your-package-under-test">
-<h2>Choose Your Package Under Test<a class="headerlink" href="#choose-your-package-under-test" title="Permalink to this headline">?</a></h2>
-<p>Choose the package you want to write a test suite for. In this tutorial,
-we will use the <code class="docutils literal notranslate"><span class="pre">time/datetime</span></code> in the apache-mynewt-core repo.
-Throughout this tutorial, we will be inside the apache-mynewt-core repo
-directory, unlike most tutorials which operate from the top-level
-project directory.</p>
-</div>
-<div class="section" id="create-a-test-package">
-<h2>Create A Test Package<a class="headerlink" href="#create-a-test-package" title="Permalink to this headline">?</a></h2>
-<p>Typically, a library has only one test package. The convention is name
-the test package by appending <code class="docutils literal notranslate"><span class="pre">/test</span></code> to the host library name. For
-example, the test package for <code class="docutils literal notranslate"><span class="pre">encoding/json</span></code> is
-<code class="docutils literal notranslate"><span class="pre">encoding/json/test</span></code>. The directory structure of the json package is
-shown below:</p>
-<div class="code c highlight-none notranslate"><div class="highlight"><pre><span></span>encoding/json
-??? include
-??? ??? json
-???     ??? json.h
-??? pkg.yml
-??? src
-??? ??? json_decode.c
-??? ??? json_encode.c
-??? test
-    ??? pkg.yml
-    ??? src
-        ??? test_json.c
-        ??? test_json.h
-        ??? test_json_utils.c
-        ??? testcases
-            ??? json_simple_decode.c
-            ??? json_simple_encode.c
-</pre></div>
-</div>
-<p>The top-level <code class="docutils literal notranslate"><span class="pre">test</span></code> directory contains the json test package. To
-create a test package for the datetime package, we need to create a
-similar package called <code class="docutils literal notranslate"><span class="pre">time/datetime/test</span></code>.</p>
-<div class="highlight-none notranslate"><div class="highlight"><pre><span></span>$ newt pkg new time/datetime/test -t unittest
-Download package template for package type pkg.
-Package successfuly installed into /home/me/mynewt-core/time/datetime/test.
-</pre></div>
-</div>
-<p>We now have a test package inside <code class="docutils literal notranslate"><span class="pre">time/datetime</span></code>:</p>
-<div class="highlight-none notranslate"><div class="highlight"><pre><span></span>time/datetime
-??? include
-??? ??? datetime
-???     ??? datetime.h
-??? pkg.yml
-??? src
-??? ??? datetime.c
-??? test
-    ??? README.md
-    ??? pkg.yml
-    ??? src
-    ??? ??? main.c
-    ??? syscfg.yml
-</pre></div>
-</div>
-<p>There is one modification we need to make to the new package before we
-can start writing unit test code. A test package needs access to the
-code it will be testing, so we need to add a dependency on
-<code class="docutils literal notranslate"><span class="pre">&#64;apache-mynewt-core/time/datetime</span></code> to our <code class="docutils literal notranslate"><span class="pre">pkg.yml</span></code> file:</p>
-<p>While we have the <code class="docutils literal notranslate"><span class="pre">pkg.yml</span></code> file open, let?s take a look at what newt
-filled in automatically:</p>
-<ul class="simple">
-<li><code class="docutils literal notranslate"><span class="pre">pkg.type:</span> <span class="pre">unittest</span></code> designates this as a test package. A <em>test
-package</em> is special in that it can be built and executed using the
-<code class="docutils literal notranslate"><span class="pre">newt</span> <span class="pre">test</span></code> command.</li>
-<li>A test package always depends on
-<code class="docutils literal notranslate"><span class="pre">&#64;apache-mynewt-core/test/testutil</span></code>. The testutil library provides
-the tools necessary for verifying package behavior,</li>
-<li>The <code class="docutils literal notranslate"><span class="pre">SELFTEST</span></code> suffix indicates that a setting should only be
-applied when the <code class="docutils literal notranslate"><span class="pre">newt</span> <span class="pre">test</span></code> command is used.</li>
-</ul>
-<p>Regarding the conditional dependency on <code class="docutils literal notranslate"><span class="pre">sys/console/stub</span></code>, the
-datetime package requires some form of console to function. In a regular
-application, the console dependency would be supplied by a higher order
-package. Because <code class="docutils literal notranslate"><span class="pre">newt</span> <span class="pre">test</span></code> runs the test package without an
-application present, the test package needs to supply all unresolved
-dependencies itself when run in self-test mode.</p>
-</div>
-<div class="section" id="create-your-test-suite-code">
-<h2>Create Your Test Suite Code<a class="headerlink" href="#create-your-test-suite-code" title="Permalink to this headline">?</a></h2>
-<p>We will be adding a <em>test suite</em> to the <code class="docutils literal notranslate"><span class="pre">main.c</span></code> file. The test suite
-will be empty for now. We also need to invoke the test suite from
-<code class="docutils literal notranslate"><span class="pre">main()</span></code>.</p>
-<p>Our <code class="docutils literal notranslate"><span class="pre">main.c</span></code> file now looks like this:</p>
-<div class="code c highlight-none notranslate"><div class="highlight"><pre><span></span>#include &quot;sysinit/sysinit.h&quot;
-#include &quot;testutil/testutil.h&quot;
-
-TEST_SUITE(test_datetime_suite) {
-    /* Empty for now; add test cases later. */
-}
-
-#if MYNEWT_VAL(SELFTEST)
-int
-main(int argc, char **argv)
-{
-    /* Initialize all packages. */
-    sysinit();
-
-    test_datetime_suite();
-
-    /* Indicate whether all test cases passed. */
-    return tu_any_failed;
-}
-#endif
-</pre></div>
-</div>
-</div>
-<div class="section" id="try-it-out">
-<h2>Try It Out<a class="headerlink" href="#try-it-out" title="Permalink to this headline">?</a></h2>
-<p>We now have a working test suite with no tests. Let?s make sure we get a
-passing result when we run <code class="docutils literal notranslate"><span class="pre">newt</span> <span class="pre">test</span></code>:</p>
-<div class="highlight-none notranslate"><div class="highlight"><pre><span></span>$ newt test time/datetime
-&lt;build output&gt;
-Executing test: /home/me/mynewt-core/bin/targets/unittest/time_datetime_test/app/time/datetime/test/time_datetime_test.elf
-Passed tests: [time/datetime/test]
-All tests passed
-</pre></div>
-</div>
-</div>
-<div class="section" id="create-a-test">
-<h2>Create a Test<a class="headerlink" href="#create-a-test" title="Permalink to this headline">?</a></h2>
-<p>To create a test within your test suite, there are two things to do.</p>
-<ol class="arabic simple">
-<li>Implement the test case function using the <code class="docutils literal notranslate"><span class="pre">testutil</span></code> macros.</li>
-<li>Call the test case function from within the test suite.</li>
-</ol>
-<p>For this tutorial we will create a test case to verify the
-<code class="docutils literal notranslate"><span class="pre">datetime_parse()</span></code> function. The <code class="docutils literal notranslate"><span class="pre">datetime_parse()</span></code> function is
-declared as follows:</p>
-<div class="code c highlight-none notranslate"><div class="highlight"><pre><span></span>/**
- * Parses an RFC 3339 datetime string.  Some examples of valid datetime strings
- * are:
- * 2016-03-02T22:44:00                  UTC time (implicit)
- * 2016-03-02T22:44:00Z                 UTC time (explicit)
- * 2016-03-02T22:44:00-08:00            PST timezone
- * 2016-03-02T22:44:00.1                fractional seconds
- * 2016-03-02T22:44:00.101+05:30        fractional seconds with timezone
- *
- * On success, the two output parameters are filled in (tv and tz).
- *
- * @return                      0 on success;
- *                              nonzero on parse error.
- */
-int
-datetime_parse(const char *input, struct os_timeval *tv, struct os_timezone *tz)
-</pre></div>
-</div>
-<p>Our test case should make sure this function rejects invalid input, and
-that it parses valid input correctly. The updated <code class="docutils literal notranslate"><span class="pre">main.c</span></code> file looks
-like this:</p>
-<div class="code c highlight-none notranslate"><div class="highlight"><pre><span></span>#include &quot;sysinit/sysinit.h&quot;
-#include &quot;testutil/testutil.h&quot;
-#include &quot;os/os_time.h&quot;
-#include &quot;datetime/datetime.h&quot;
-
-TEST_SUITE(test_datetime_suite)
-{
-    test_datetime_parse_simple();
-}
-
-TEST_CASE(test_datetime_parse_simple)
-{
-    struct os_timezone tz;
-    struct os_timeval tv;
-    int rc;
-
-    /*** Valid input. */
-
-    /* No timezone; UTC implied. */
-    rc = datetime_parse(&quot;2017-06-28T22:37:59&quot;, &amp;tv, &amp;tz);
-    TEST_ASSERT_FATAL(rc == 0);
-    TEST_ASSERT(tv.tv_sec == 1498689479);
-    TEST_ASSERT(tv.tv_usec == 0);
-    TEST_ASSERT(tz.tz_minuteswest == 0);
-    TEST_ASSERT(tz.tz_dsttime == 0);
-
-    /* PDT timezone. */
-    rc = datetime_parse(&quot;2013-12-05T02:43:07-07:00&quot;, &amp;tv, &amp;tz);
-    TEST_ASSERT_FATAL(rc == 0);
-    TEST_ASSERT(tv.tv_sec == 1386236587);
-    TEST_ASSERT(tv.tv_usec == 0);
-    TEST_ASSERT(tz.tz_minuteswest == 420);
-    TEST_ASSERT(tz.tz_dsttime == 0);
-
-    /*** Invalid input. */
-
-    /* Nonsense. */
-    rc = datetime_parse(&quot;abc&quot;, &amp;tv, &amp;tz);
-    TEST_ASSERT(rc != 0);
-
-    /* Date-only. */
-    rc = datetime_parse(&quot;2017-01-02&quot;, &amp;tv, &amp;tz);
-    TEST_ASSERT(rc != 0);
-
-    /* Zero month. */
-    rc = datetime_parse(&quot;2017-00-28T22:37:59&quot;, &amp;tv, &amp;tz);
-    TEST_ASSERT(rc != 0);
-
-    /* 13 month. */
-    rc = datetime_parse(&quot;2017-13-28T22:37:59&quot;, &amp;tv, &amp;tz);
-    TEST_ASSERT(rc != 0);
-}
-
-#if MYNEWT_VAL(SELFTEST)
-int
-main(int argc, char **argv)
-{
-    /* Initialize all packages. */
-    sysinit();
-
-    test_datetime_suite();
-
-    /* Indicate whether all test cases passed. */
-    return tu_any_failed;
-}
-#endif
-</pre></div>
-</div>
-<p>Take a few minutes to review the above code. Then keep reading for some
-specifics.</p>
-<div class="section" id="asserting">
-<h3>Asserting<a class="headerlink" href="#asserting" title="Permalink to this headline">?</a></h3>
-<p>The <code class="docutils literal notranslate"><span class="pre">test/testutil</span></code> package provides two tools for verifying the
-correctness of a package:</p>
-<ul class="simple">
-<li><code class="docutils literal notranslate"><span class="pre">TEST_ASSERT</span></code></li>
-<li><code class="docutils literal notranslate"><span class="pre">TEST_ASSERT_FATAL</span></code></li>
-</ul>
-<p>Both of these macros check if the supplied condition is true. They
-differ in how they behave when the condition is not true. On failure,
-<code class="docutils literal notranslate"><span class="pre">TEST_ASSERT</span></code> reports the error and proceeds with the remainder of the
-test case. <code class="docutils literal notranslate"><span class="pre">TEST_ASSERT_FATAL</span></code>, on the other hand, aborts the test
-case on failure.</p>
-<p>The general rule is to only use <code class="docutils literal notranslate"><span class="pre">TEST_ASSERT_FATAL</span></code> when subsequent
-assertions depend on the condition being checked. For example, when
-<code class="docutils literal notranslate"><span class="pre">datetime_parse()</span></code> is expected to succeed, the return code is checked
-with <code class="docutils literal notranslate"><span class="pre">TEST_ASSERT_FATAL</span></code>. If <code class="docutils literal notranslate"><span class="pre">datetime_parse()</span></code> unexpectedly failed,
-the contents of the <code class="docutils literal notranslate"><span class="pre">tv</span></code> and <code class="docutils literal notranslate"><span class="pre">tz</span></code> objects would be indeterminate, so
-it is desirable to abort the test instead of checking them and reporting
-spurious failures.</p>
-</div>
-<div class="section" id="scaling-up">
-<h3>Scaling Up<a class="headerlink" href="#scaling-up" title="Permalink to this headline">?</a></h3>
-<p>The above example is small and self contained, so it is reasonable to
-put everything in a single C file. A typical package will need a lot
-more test code, and it helps to follow some conventions to maintain
-organization. Let?s take a look at a more realistic example. Here is the
-directory structure of the <code class="docutils literal notranslate"><span class="pre">fs/nffs/test</span></code> package:</p>
-<div class="highlight-none notranslate"><div class="highlight"><pre><span></span>fs/nffs/test
-??? pkg.yml
-??? src
-    ??? nffs_test.c
-    ??? nffs_test.h
-    ??? nffs_test_debug.c
-    ??? nffs_test_priv.h
-    ??? nffs_test_system_01.c
-    ??? nffs_test_utils.c
-    ??? nffs_test_utils.h
-    ??? testcases
-        ??? append_test.c
-        ??? cache_large_file_test.c
-        ??? corrupt_block_test.c
-        ??? corrupt_scratch_test.c
-        ??? gc_on_oom_test.c
-        ??? gc_test.c
-        ??? incomplete_block_test.c
-        ??? large_system_test.c
-        ??? large_unlink_test.c
-        ??? large_write_test.c
-        ??? long_filename_test.c
-        ??? lost_found_test.c
-        ??? many_children_test.c
-        ??? mkdir_test.c
-        ??? open_test.c
-        ??? overwrite_many_test.c
-        ??? overwrite_one_test.c
-        ??? overwrite_three_test.c
-        ??? overwrite_two_test.c
-        ??? read_test.c
-        ??? readdir_test.c
-        ??? rename_test.c
-        ??? split_file_test.c
-        ??? truncate_test.c
-        ??? unlink_test.c
-        ??? wear_level_test.c
-</pre></div>
-</div>
-<p>The <code class="docutils literal notranslate"><span class="pre">fs/nffs/test</span></code> package follows these conventions:</p>
-<ol class="arabic simple">
-<li>A maximum of one test case per C file.</li>
-<li>Each test case file goes in the <code class="docutils literal notranslate"><span class="pre">testcases</span></code> subdirectory.</li>
-<li>Test suites and utility functions go directly in the <code class="docutils literal notranslate"><span class="pre">src</span></code>
-directory.</li>
-</ol>
-<p>Test packages contributed to the Mynewt project should follow these
-conventions.</p>
-</div>
-</div>
-<div class="section" id="congratulations">
-<h2>Congratulations<a class="headerlink" href="#congratulations" title="Permalink to this headline">?</a></h2>
-<p>Now you can begin the work of validating your packages.</p>
-</div>
-</div>
-
-
-                   </div>
-                  </div>
-                  
-                </div>
-              </div>
-            </div>
-            <!-- ENDS CONTENT SECTION -->
-          </div>
-          <!-- ENDS .content -->
-        </div>
-      </div>
-      <footer>
-  <div class="container">
-    <div class="row">
-      <div class="col-xs-12">
-          
-              <p class="copyright">Apache Mynewt is available under Apache License, version 2.0.</p>
-          
-      </div>
-      <div class="col-xs-12">
-          <div class="logos">
-              <img src="../../_static/img/asf_logo_wide_small.png" alt="Apache" title="Apache">
-              <small class="footnote">
-                Apache Mynewt, Mynewt, Apache, the Apache feather logo, and the Apache Mynewt project logo are either
-                registered trademarks or trademarks of the Apache Software Foundation in the United States and other countries.
-              </small>
-              <a href="https://join.slack.com/mynewt/shared_invite/MTkwMTg1ODM1NTg5LTE0OTYxNzQ4NzQtZTU1YmNhYjhkMg">
-                <img src="../../_static/img/add_to_slack.png" alt="Slack Icon" title="Join our Slack Community" />
-              </a>
-          </div>
-      </div>
-    </div>
-  </div>
-</footer>
-    </div>
-    <!-- ENDS #wrapper -->
-
-  
-
-    <script type="text/javascript">
-        var DOCUMENTATION_OPTIONS = {
-            URL_ROOT:'../../',
-            VERSION:'1.3.0',
-            COLLAPSE_INDEX:false,
-            FILE_SUFFIX:'.html',
-            HAS_SOURCE:  true,
-            SOURCELINK_SUFFIX: '.txt'
-        };
-    </script>
-      <script type="text/javascript" src="../../_static/jquery.js"></script>
-      <script type="text/javascript" src="../../_static/underscore.js"></script>
-      <script type="text/javascript" src="../../_static/doctools.js"></script>
-      <script type="text/javascript" src="../../_static/js/bootstrap-3.0.3.min.js"></script>
-      <script type="text/javascript" src="../../_static/js/affix.js"></script>
-      <script type="text/javascript" src="../../_static/js/main.js"></script>
-
-   
-
-  </body>
-</html>
\ No newline at end of file
diff --git a/develop/os/tutorials/wi-fi_on_arduino.html b/develop/os/tutorials/wi-fi_on_arduino.html
deleted file mode 100644
index bdc7056b8..000000000
--- a/develop/os/tutorials/wi-fi_on_arduino.html
+++ /dev/null
@@ -1,601 +0,0 @@
-
-
-<!DOCTYPE html>
-<html lang="en">
-  <head>
-    <meta charset="utf-8">
-    <meta http-equiv="X-UA-Compatible" content="IE=edge">
-    <meta name="viewport" content="width=device-width, initial-scale=1.0">
-
-    
-
-    
-    <title>Enable Wi-Fi on Arduino MKR1000 &mdash; Apache Mynewt 1.3.0 documentation</title>
-    
-
-    
-    
-      <link rel="shortcut icon" href="../../_static/mynewt-logo-only-newt32x32.png"/>
-    
-
-    
-
-    <link rel="stylesheet" href="../../_static/css/theme.css" type="text/css" />
-
-    
-      <link rel="stylesheet" href="../../_static/css/sphinx_theme.css" type="text/css" />
-    
-      <link rel="stylesheet" href="../../_static/css/bootstrap-3.0.3.min.css" type="text/css" />
-    
-      <link rel="stylesheet" href="../../_static/css/v2.css" type="text/css" />
-    
-      <link rel="stylesheet" href="../../_static/css/custom.css" type="text/css" />
-    
-      <link rel="stylesheet" href="../../_static/css/restructuredtext.css" type="text/css" />
-    
-
-    
-
-    <link rel="stylesheet" href="../../_static/css/overrides.css" type="text/css" />
-          <link rel="index" title="Index"
-                href="../../genindex.html"/>
-          <link rel="search" title="Search" href="../../search.html"/>
-      <link rel="top" title="Apache Mynewt 1.3.0 documentation" href="../../index.html"/> 
-
-    
-    <script src="../../_static/js/modernizr.min.js"></script>
-
-    
-    <script>
-    (function(i, s, o, g, r, a, m) {
-	i["GoogleAnalyticsObject"] = r;
-	(i[r] =
-		i[r] ||
-		function() {
-			(i[r].q = i[r].q || []).push(arguments);
-		}),
-		(i[r].l = 1 * new Date());
-	(a = s.createElement(o)), (m = s.getElementsByTagName(o)[0]);
-	a.async = 1;
-	a.src = g;
-	m.parentNode.insertBefore(a, m);
-})(window, document, "script", "//www.google-analytics.com/analytics.js", "ga");
-
-ga("create", "UA-72162311-1", "auto");
-ga("send", "pageview");
-</script>
-    
-
-  </head>
-
-  <body class="not-front page-documentation" role="document" >
-    <div id="wrapper">
-      <div class="container">
-    <div id="banner" class="row v2-main-banner">
-        <a class="logo-cell" href="/">
-            <img class="logo" src="../../_static/img/logo.png">
-        </a>
-        <div class="tagline-cell">
-            <h4 class="tagline">An OS to build, deploy and securely manage billions of devices</h4>
-        </div>
-        <div class="news-cell">
-            <div class="well">
-              <h4>Latest News:</h4> <a href="/download">Apache Mynewt 1.3.0</a> released (December 13, 2017)
-            </div>
-        </div>
-    </div>
-</div>
-      
-<header>
-    <nav id="navbar" class="navbar navbar-inverse" role="navigation">
-        <div class="container">
-            <!-- Collapsed navigation -->
-            <div class="navbar-header">
-                <!-- Expander button -->
-                <button type="button" class="navbar-toggle" data-toggle="collapse" data-target=".navbar-collapse">
-                    <span class="sr-only">Toggle navigation</span>
-                    <span class="icon-bar"></span>
-                    <span class="icon-bar"></span>
-                    <span class="icon-bar"></span>
-                </button>
-
-            </div>
-
-            <!-- Expanded navigation -->
-            <div class="navbar-collapse collapse">
-                <!-- Main navigation -->
-                <ul class="nav navbar-nav navbar-right">
-                    <li>
-                        <a href="/"><i class="fa fa-home" style="font-size: larger;"></i></a>
-                    </li>
-                    <li class="important">
-                        <a href="/get_started/quick_start.html">Quick Start</a>
-                    </li>
-                    <li>
-                        <a href="/about/">About</a>
-                    </li>
-                    <li>
-                        <a href="/talks/">Talks</a>
-                    </li>
-                    <li class="active">
-                        <a href="/documentation/">Documentation</a>
-                    </li>
-                    <li>
-                        <a href="/download/">Download</a>
-                    </li>
-                    <li>
-                        <a href="/community/">Community</a>
-                    </li>
-                    <li>
-                        <a href="/events/">Events</a>
-                    </li>
-                </ul>
-
-                <!-- Search, Navigation and Repo links -->
-                <ul class="nav navbar-nav navbar-right">
-                    
-                </ul>
-            </div>
-        </div>
-    </nav>
-</header>
-      <!-- STARTS MAIN CONTENT -->
-      <div id="main-content">
-        
-
-
-
-
-
-<div id="breadcrumb">
-  <div class="container">
-    <a href="/documentation/">Docs</a> /
-    
-    Enable Wi-Fi on Arduino MKR1000
-    
-  <div class="sourcelink">
-    <a href="https://github.com/apache/mynewt-core/edit/master/docs/os/tutorials/wi-fi_on_arduino.rst" class="icon icon-github"
-           rel="nofollow"> Edit on GitHub</a>
-</div>
-  </div>
-</div>
-        <!-- STARTS CONTAINER -->
-        <div class="container">
-          <!-- STARTS .content -->
-          <div id="content" class="row">
-            
-            <!-- STARTS .container-sidebar -->
-<div class="container-sidebar col-xs-12 col-sm-3">
-  <div id="docSidebar" class="sticky-container">
-    <div role="search" class="sphinx-search">
-  <form id="rtd-search-form" class="wy-form" action="../../search.html" method="get">
-    <input type="text" name="q" placeholder="Search documentation" class="search-documentation" />
-    <input type="hidden" name="check_keywords" value="yes" />
-    <input type="hidden" name="area" value="default" />
-  </form>
-</div>
-    
-<!-- Note: only works when deployed -->
-<select class="form-control" onchange="if (this.value) window.location.href=this.value">
-    <option
-      value="/develop"
-      selected
-      >
-      Version: develop (latest - mynewt-documentation)
-    </option>
-    <option
-      value="/latest/os/introduction"
-      >
-      Version: master (latest - mynewt-site)
-    </option>
-    <option
-      value="/v1_2_0/os/introduction"
-      >
-      Version: 1.2.0
-    </option>
-    <option
-      value="/v1_1_0/os/introduction">
-      Version: 1.1.0
-    </option>
-    <option
-      value="/v1_0_0/os/introduction">
-      Version: 1.0.0
-    </option>
-    <option
-      value="/v0_9_0/os/introduction">
-      Version: 0_9_0
-    </option>
-</select>
-    <div class="region region-sidebar">
-      <div class="docs-menu">
-      
-        
-        
-            <ul>
-<li class="toctree-l1"><a class="reference internal" href="../../index.html">Introduction</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../get_started/index.html">Setup &amp; Get Started</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../concepts.html">Concepts</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../tutorials/tutorials.html">Tutorials</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../os_user_guide.html">OS User Guide</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../network/ble/ble_intro.html">BLE User Guide</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../newt/index.html">Newt Tool Guide</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../newtmgr/index.html">Newt Manager Guide</a></li>
-<li class="toctree-l1"><a class="reference internal" href="../../misc/index.html">Appendix</a></li>
-</ul>
-
-        
-      
-      </div>
-    </div>
-  </div>
-  <!-- ENDS STICKY CONTAINER -->
-</div>
-<!-- ENDS .container-sidebar -->
-
-            <div class="col-xs-12 col-sm-9">
-              <div class="alert alert-info" role="alert">
-  <p>
-    This is the development version of Apache Mynewt documentation. As such it may not be as complete as the latest
-    stable version of the documentation found <a href="/latest/os/introduction/">here</a>.
-  </p>
-  <p>
-    To improve this documentation please visit <a href="https://github.com/apache/mynewt-documentation">https://github.com/apache/mynewt-documentation</a>.
-  </p>
-</div>
-              
-              <div class="">
-                <div class="rst-content">
-                  <div role="main" class="document" itemscope="itemscope" itemtype="http://schema.org/Article">
-                   <div itemprop="articleBody">
-                    
-  <div class="section" id="enable-wi-fi-on-arduino-mkr1000">
-<h1>Enable Wi-Fi on Arduino MKR1000<a class="headerlink" href="#enable-wi-fi-on-arduino-mkr1000" title="Permalink to this headline">?</a></h1>
-<p>This tutorial shows you how to enable Wi-Fi on an Arduino MKR1000 board
-and connect to a Wi-Fi network.</p>
-<div class="section" id="prerequisites">
-<h2>Prerequisites<a class="headerlink" href="#prerequisites" title="Permalink to this headline">?</a></h2>
-<p>Ensure that you have met the following prerequisites before continuing
-with this tutorial:</p>
-<ul class="simple">
-<li>Have an Arduino MKR1000 board.</li>
-<li>Have Internet connectivity to fetch remote Mynewt components.</li>
-<li>Have a computer to build a Mynewt application and connect to the
-board over USB.</li>
-<li>Have a Micro-USB cable to connect the board and the computer.</li>
-<li>Have local Wi-Fi network that the computer is connected to and that
-the MKR1000 board can join.</li>
-<li>Have a <a class="reference external" href="/os/get_started/serial_access.html">Serial Port Setup</a>.</li>
-<li>Have a <a class="reference external" href="https://www.segger.com/jlink-debug-probes.html">Segger J-Link Debug
-Probe</a>.</li>
-<li>Have a <a class="reference external" href="https://www.segger.com/jlink-adapters.html#CM_9pin">J-Link 9 pin Cortex-M
-Adapter</a> that
-allows JTAG, SWD and SWO connections between J-Link and Cortex M
-based target hardware systems</li>
-<li>Install the <a class="reference external" href="https://www.segger.com/jlink-software.html">Segger JLINK Software and documentation
-pack</a>.</li>
-<li>Install the Newt tool and toolchains (See <a class="reference external" href="/os/get_started/get_started.html">Basic
-Setup</a>).</li>
-<li>Create a project space (directory structure) and populated it with
-the core code repository (apache-mynewt-core) or know how to as
-explained in <a class="reference external" href="/os/get_started/project_create">Creating Your First
-Project</a>.</li>
-<li>Read the Mynewt OS <a class="reference external" href="/os/get_started/vocabulary.html">Concepts</a>
-section.</li>
-</ul>
-</div>
-<div class="section" id="create-a-project">
-<h2>Create a Project<a class="headerlink" href="#create-a-project" title="Permalink to this headline">?</a></h2>
-<p>Create a new project if you do not have an existing one. You can skip
-this step and proceed to <a class="reference external" href="#%20fetchexternal">fetch external packages</a>
-if you already created a project.</p>
-<p>Run the following commands to create a new project:</p>
-<div class="highlight-console notranslate"><div class="highlight"><pre><span></span><span class="gp">$</span> mkdir ~/dev
-<span class="gp">$</span> <span class="nb">cd</span> ~/dev
-<span class="gp">$</span> newt new arduinowifi
-<span class="go">Downloading project skeleton from apache/mynewt-blinky...</span>
-<span class="go">Installing skeleton in arduinowifi...</span>
-<span class="go">Project arduinowifi successfully created.</span>
-<span class="gp">$</span> <span class="nb">cd</span> arduinowifi
-<span class="gp">$</span> newt install
-<span class="go">apache-mynewt-core</span>
-<span class="gp">$</span>
-</pre></div>
-</div>
-</div>
-<div class="section" id="fetch-external-packages">
-<h2>Fetch External Packages<a class="headerlink" href="#fetch-external-packages" title="Permalink to this headline">?</a></h2>
-<p>Mynewt uses source code provided directly from the chip manufacturer for
-low level operations. Sometimes this code is licensed only for the
-specific manufacturer of the chipset and cannot live in the Apache
-Mynewt repository. That happens to be the case for the Arduino Zero
-board which uses Atmel SAMD21. Runtime?s git hub repository hosts such
-external third-party packages and the Newt tool can fetch them.</p>
-<p>To fetch the package with MCU support for Atmel SAMD21 for Arduino Zero
-from the Runtime git repository, you need to add the repository to the
-<code class="docutils literal notranslate"><span class="pre">project.yml</span></code> file in your base project directory.</p>
-<p>Mynewt uses source code provided directly from the chip manufacturer for
-low level operations. Sometimes this code is licensed only for the
-specific manufacturer of the chipset and cannot live in the Apache
-Mynewt repository. That happens to be the case for the Arduino Zero
-board which uses Atmel SAMD21. Runtime?s github repository hosts such
-external third-party packages and the Newt tool can fetch them.</p>
-<p>To fetch the package with MCU support for Atmel SAMD21 for Arduino Zero
-from the Runtime git repository, you need to add the repository to the
-<code class="docutils literal notranslate"><span class="pre">project.yml</span></code> file in your base project directory (<code class="docutils literal notranslate"><span class="pre">arduinowifi</span></code>).</p>
-<p>Here is an example <code class="docutils literal notranslate"><span class="pre">project.yml</span></code> file with the Arduino Zero repository
-added. The sections with <code class="docutils literal notranslate"><span class="pre">mynewt_arduino_zero</span></code> that need to be added
-to your project file are highlighted.</p>
-<p><strong>Note:</strong> On Windows platforms: You need to set <code class="docutils literal notranslate"><span class="pre">vers</span></code> to <code class="docutils literal notranslate"><span class="pre">0-dev</span></code>
-and use the latest master branch for both repositories.</p>
-<p>```hl_lines=?6 14 15 16 17 18? $ more project.yml project.name:
-?my_project?</p>
-<p>project.repositories: - apache-mynewt-core - mynewt_arduino_zero</p>
-<p>repository.apache-mynewt-core: type: github vers: 1-latest user: apache
-repo: mynewt-core</p>
-<p>repository.mynewt_arduino_zero: type: github vers: 1-latest user:
-runtimeco repo: mynewt_arduino_zero $ ```</p>
-<p>Install the project dependencies using the <code class="docutils literal notranslate"><span class="pre">newt</span> <span class="pre">install</span></code> command
-(you can specify <code class="docutils literal notranslate"><span class="pre">-v</span></code> for verbose output):</p>
-<div class="highlight-console notranslate"><div class="highlight"><pre><span></span><span class="gp">$</span> newt install
-<span class="go">apache-mynewt-core</span>
-<span class="go">mynewt_arduino_zero</span>
-<span class="gp">$</span>
-</pre></div>
-</div>
-<p><strong>NOTE:</strong> If there has been a new release of a repo used in your project
-since you last installed it, the <code class="docutils literal notranslate"><span class="pre">1-latest</span></code> version for the repo in
-the <code class="docutils literal notranslate"><span class="pre">project.yml</span></code> file will refer to the new release and will not
-match the installed files. In that case you will get an error message
-saying so and you will need to run <code class="docutils literal notranslate"><span class="pre">newt</span> <span class="pre">upgrade</span></code> to overwrite the
-existing files with the latest codebase.</p>
-</div>
-<div class="section" id="create-a-target-for-the-bootloader">
-<h2>Create a Target for the Bootloader<a class="headerlink" href="#create-a-target-for-the-bootloader" title="Permalink to this headline">?</a></h2>
-<p>You need to create two targets for the MKR1000 board, one for the
-bootloader and one for the <code class="docutils literal notranslate"><span class="pre">winc1500_wifi</span></code> application. Run the
-following <code class="docutils literal notranslate"><span class="pre">newt</span> <span class="pre">target</span></code> commands, from your project directory, to
-create a bootloader target. We name the target <code class="docutils literal notranslate"><span class="pre">mkr1000_boot</span></code>.</p>
-<div class="highlight-console notranslate"><div class="highlight"><pre><span></span><span class="gp">$</span> newt target create mkr1000_boot
-<span class="gp">$</span> newt target <span class="nb">set</span> mkr1000_boot <span class="nv">bsp</span><span class="o">=</span>@mynewt_arduino_zero/hw/bsp/arduino_mkr1000
-<span class="gp">$</span> newt target <span class="nb">set</span> mkr1000_boot <span class="nv">app</span><span class="o">=</span>@apache-mynewt-core/apps/boot
-<span class="gp">$</span> newt target <span class="nb">set</span> mkr1000_boot <span class="nv">build_profile</span><span class="o">=</span>optimized
-<span class="gp">$</span> newt target <span class="nb">set</span> mkr1000_boot <span class="nv">syscfg</span><span class="o">=</span><span class="nv">BSP_ARDUINO_ZERO_PRO</span><span class="o">=</span><span class="m">1</span>
-</pre></div>
-</div>
-</div>
-<div class="section" id="create-a-target-for-the-wi-fi-application">
-<h2>Create a Target for the Wi-Fi Application<a class="headerlink" href="#create-a-target-for-the-wi-fi-application" title="Permalink to this headline">?</a></h2>
-<p>Run the following <code class="docutils literal notranslate"><span class="pre">newt</span> <span class="pre">target</span></code> commands to create a target for the
-<code class="docutils literal notranslate"><span class="pre">winc1500_wifi</span></code> application in the arduino repository. We name the
-application target <code class="docutils literal notranslate"><span class="pre">mkr1000_wifi</span></code>.</p>
-<div class="highlight-none notranslate"><div class="highlight"><pre><span></span>$ newt target create mkr1000_wifi
-$ newt target set mkr1000_wifi app=@mynewt_arduino_zero/apps/winc1500_wifi
-$ newt target set mkr1000_wifi bsp=@mynewt_arduino_zero/hw/bsp/arduino_mkr1000
-$ newt target set mkr1000_wifi build_profile=debug
-$ newt target set mkr1000_boot syscfg=BSP_ARDUINO_ZERO_PRO=1
-</pre></div>
-</div>
-</div>
-<div class="section" id="build-the-bootloader">
-<h2>Build the Bootloader<a class="headerlink" href="#build-the-bootloader" title="Permalink to this headline">?</a></h2>
-<p>Run the <code class="docutils literal notranslate"><span class="pre">newt</span> <span class="pre">build</span> <span class="pre">mkr1000_boot</span></code> command to build the bootloader:</p>
-<div class="highlight-console notranslate"><div class="highlight"><pre><span></span><span class="gp">$</span> newt build mkr1000_boot
-<span class="go">Building target targets/mkr1000_boot</span>
-<span class="go">Compiling repos/apache-mynewt-core/boot/bootutil/src/image_rsa.c</span>
-<span class="go">Compiling repos/apache-mynewt-core/boot/bootutil/src/image_ec256.c</span>
-<span class="go">Compiling repos/apache-mynewt-core/crypto/mbedtls/src/aes.c</span>
-<span class="go">Compiling repos/apache-mynewt-core/boot/bootutil/src/image_ec.c</span>
-<span class="go">Compiling repos/apache-mynewt-core/boot/bootutil/src/image_validate.c</span>
-<span class="go">Compiling repos/apache-mynewt-core/apps/boot/src/boot.c</span>
-
-<span class="go">       ...</span>
-
-<span class="go">Archiving util_mem.a</span>
-<span class="go">Linking ~/dev/arduinowifi/bin/targets/mkr1000_boot/app/apps/boot/boot.elf</span>
-<span class="go">Target successfully built: targets/mkr1000_boot</span>
-<span class="gp">$</span>
-</pre></div>
-</div>
-</div>
-<div class="section" id="build-the-wi-fi-application">
-<h2>Build the Wi-Fi Application<a class="headerlink" href="#build-the-wi-fi-application" title="Permalink to this headline">?</a></h2>
-<p>Run the <code class="docutils literal notranslate"><span class="pre">newt</span> <span class="pre">build</span> <span class="pre">mkr1000_wifi</span></code> command to build the wi-fi
-application image:</p>
-<div class="highlight-console notranslate"><div class="highlight"><pre><span></span><span class="gp">$</span>newt build mkr1000_wifi
-<span class="go">Building target targets/mkr1000_wifi</span>
-<span class="go">Compiling repos/apache-mynewt-core/boot/bootutil/src/image_ec.c</span>
-<span class="go">Compiling repos/apache-mynewt-core/boot/bootutil/src/image_ec256.c</span>
-<span class="go">Compiling repos/apache-mynewt-core/boot/bootutil/src/image_rsa.c</span>
-<span class="go">Compiling repos/apache-mynewt-core/boot/bootutil/src/image_validate.c</span>
-<span class="go">Compiling repos/apache-mynewt-core/boot/bootutil/src/loader.c</span>
-<span class="go">           ...</span>
-
-<span class="go">Archiving util_mem.a</span>
-<span class="go">Linking ~/dev/arduinowifi/bin/targets/mkr1000_wifi/app/apps/winc1500_wifi/winc1500_wifi.elf</span>
-<span class="go">Target successfully built: targets/mkr1000_wifi</span>
-<span class="gp">$</span>
-</pre></div>
-</div>
-</div>
-<div class="section" id="sign-and-create-the-wi-fi-application-image">
-<h2>Sign and Create the Wi-Fi Application Image<a class="headerlink" href="#sign-and-create-the-wi-fi-application-image" title="Permalink to this headline">?</a></h2>
-<p>Run the <code class="docutils literal notranslate"><span class="pre">newt</span> <span class="pre">create-image</span> <span class="pre">mkr1000_wifi</span> <span class="pre">1.0.0</span></code> command to sign and
-create an image file for the Wi-Fi application. You may assign an
-arbitrary version (e.g. 1.0.0) number.</p>
-<div class="highlight-console notranslate"><div class="highlight"><pre><span></span><span class="gp">$</span>newt create-image  mkr1000_wifi <span class="m">1</span>.0.0
-<span class="go">Compiling bin/targets/mkr1000_wifi/generated/src/mkr1000_wifi-sysinit-app.c</span>
-<span class="go">Archiving mkr1000_wifi-sysinit-app.a</span>
-<span class="go">Linking ~/dev/arduinowifi/bin/targets/mkr1000_wifi/app/apps/winc1500_wifi/winc1500_wifi.elf</span>
-<span class="go">App image succesfully generated: ~/dev/arduinowifi/bin/targets/mkr1000_wifi/app/apps/winc1500_wifi/winc1500_wifi.img</span>
-<span class="gp">$</span>
-</pre></div>
-</div>
-</div>
-<div class="section" id="connect-to-the-board">
-<h2>Connect to the Board<a class="headerlink" href="#connect-to-the-board" title="Permalink to this headline">?</a></h2>
-<ul class="simple">
-<li>Connect your computer to the MKR1000 board with the Micro-USB cable.</li>
-<li>Connect the debug probe to the JTAG port on the board using the Jlink
-9-pin adapter and cable.</li>
-</ul>
-<blockquote>
-<div><img alt="J-Link debug probe to MKR1000" src="os/tutorials/pics/mkr1000-jlink.jpg" /></div></blockquote>
-<p><p>Mynewt will download and debug the target through this port. You should
-see a green LED come on and indicates the board has power.</p>
-</div>
-<div class="section" id="load-the-bootloader-onto-the-board">
-<h2>Load the Bootloader onto the Board<a class="headerlink" href="#load-the-bootloader-onto-the-board" title="Permalink to this headline">?</a></h2>
-<p>Run the <code class="docutils literal notranslate"><span class="pre">newt</span> <span class="pre">load</span> <span class="pre">mkr1000_boot</span></code> command to load the bootloader onto
-the board:</p>
-<div class="highlight-console notranslate"><div class="highlight"><pre><span></span><span class="gp">$</span> newt load mkr1000_boot
-<span class="go">Loading bootloader</span>
-<span class="gp">$</span>
-</pre></div>
-</div>
-</div>
-<div class="section" id="load-the-wi-fi-application-image-onto-the-board">
-<h2>Load the Wi-Fi Application Image onto the Board<a class="headerlink" href="#load-the-wi-fi-application-image-onto-the-board" title="Permalink to this headline">?</a></h2>
-<p>Run the <code class="docutils literal notranslate"><span class="pre">newt</span> <span class="pre">load</span> <span class="pre">mkr1000_wifi</span></code> command to load the wifi application
-onto the board:</p>
-<div class="highlight-console notranslate"><div class="highlight"><pre><span></span><span class="gp">$</span> newt load mkr1000_wifi
-<span class="go">Loading app image into slot 1</span>
-<span class="gp">$</span>
-</pre></div>
-</div>
-</div>
-<div class="section" id="setup-a-serial-connection-between-your-computer-and-the-board">
-<h2>Setup a Serial Connection Between Your Computer and the Board<a class="headerlink" href="#setup-a-serial-connection-between-your-computer-and-the-board" title="Permalink to this headline">?</a></h2>
-<p>Set up a serial connection from your computer to the MKR1000 board (See
-<a class="reference external" href="/os/get_started/serial_access.html">Serial Port Setup</a>). On the
-MKR1000 board, the TX pin is PIN 14 and the RX pin in PIN 13. <img alt="Serial Connection to MKR1000" src="os/tutorials/pics/mkr1000-serial.jpg" /></p>
-<p><p>Locate the port, in the /dev directory on your computer, that the
-serial connection uses. The format of the port name is platform
-dependent:</p>
-<ul>
-<li><p class="first">Mac OS uses the format <code class="docutils literal notranslate"><span class="pre">tty.usbserial-&lt;some</span> <span class="pre">identifier&gt;</span></code>.</p>
-</li>
-<li><p class="first">Linux uses the format <code class="docutils literal notranslate"><span class="pre">TTYUSB&lt;N&gt;</span></code>, where <code class="docutils literal notranslate"><span class="pre">N</span></code> is a number. For
-example, TTYUSB2.</p>
-</li>
-<li><p class="first">MinGW on Windows uses the format <code class="docutils literal notranslate"><span class="pre">ttyS&lt;N&gt;</span></code>, where <code class="docutils literal notranslate"><span class="pre">N</span></code> is a
-number. You must map the port name to a Windows COM port:
-<code class="docutils literal notranslate"><span class="pre">/dev/ttyS&lt;N&gt;</span></code> maps to <code class="docutils literal notranslate"><span class="pre">COM&lt;N+1&gt;</span></code>. For example, <code class="docutils literal notranslate"><span class="pre">/dev/ttyS2</span></code>
-maps to <code class="docutils literal notranslate"><span class="pre">COM3</span></code>.</p>
-<p>You can also use the Windows Device Manager to find the COM port
-number.</p>
-</li>
-</ul>
-<div class="highlight-console notranslate"><div class="highlight"><pre><span></span><span class="gp">$</span> ls /dev/tty*usbserial*
-<span class="go">/dev/tty.usbserial-1d13</span>
-<span class="gp">$</span>
-</pre></div>
-</div>
-</div>
-<div class="section" id="start-wi-fi-via-console">
-<h2>Start Wi-Fi via console<a class="headerlink" href="#start-wi-fi-via-console" title="Permalink to this headline">?</a></h2>
-<p>Use a terminal emulation program to communicate with the board over the
-serial port. This tutorial shows a Minicom set up. Run the minicom
-command with the serial port you located on your computer:</p>
-<p><strong>Note:</strong> On Windows, you can use the PuTTY application.</p>
-<div class="highlight-console notranslate"><div class="highlight"><pre><span></span><span class="gp">$</span> minicom -D /dev/tty.usbserial-1d13 -b <span class="m">115200</span>
-</pre></div>
-</div>
-<p>Type <code class="docutils literal notranslate"><span class="pre">wifi</span> <span class="pre">start</span></code> to start Wi-Fi.</p>
-<p>Connect to the local Wi-Fi network. Note that the MKR1000 board only
-supports 2.4 GHz Wi-Fi networks.</p>
-<p>Run the <code class="docutils literal notranslate"><span class="pre">wifi</span> <span class="pre">connect</span></code> command and specify your network and . After
-you are connected to your wi-fi network, run the <code class="docutils literal notranslate"><span class="pre">net</span> <span class="pre">service</span></code> command
-to start network services.</p>
-<p>```hl_lines=?2 9?</p>
-<p>wifi connect 037624 wifi_request_scan : 0 037627 compat&gt; scan_results
-7: 0 038454 wifi_connect : 0 039451 connect_done : 0 039958 dhcp done
-192.168.0.135 040169 get sys time response 2017.7.12-22.41.33 net
-service</p>
-<p>```</p>
-<p>The board is connected to the network succesfully and has IP address:
-192.168.0.135</p>
-</div>
-<div class="section" id="establish-tcp-connection-and-talk">
-<h2>Establish TCP Connection and Talk!<a class="headerlink" href="#establish-tcp-connection-and-talk" title="Permalink to this headline">?</a></h2>
-<p>From a terminal on your computer, telnet to ports 7, 9, or 19 using the
-IP address your board has been assigned. Type something on this terminal
-and see the console output (on minicom). Can you see the difference in
-the behaviors?</p>
-<div class="highlight-console notranslate"><div class="highlight"><pre><span></span><span class="gp">$</span>telnet  <span class="m">192</span>.168.0.135 <span class="m">7</span>
-<span class="go">Trying 192.168.0.135...</span>
-<span class="go">Connected to 192.168.0.135.</span>
-<span class="go">Escape character is &#39;^]&#39;.</span>
-<span class="go">hello</span>
-<span class="go">hello</span>
-<span class="go">^]</span>
-<span class="go">telnet&gt; q</span>
-<span class="gp">$</span>
-</pre></div>
-</div>
-<p>One port echoes whatever is typed, one discards everything it gets, and
-the third spews out bits constantly. Type <code class="docutils literal notranslate"><span class="pre">wifi</span> <span class="pre">stop</span></code> to disable WiFi
-on the Arduino board.</p>
-</div>
-</div>
-
-
-                   </div>
-                  </div>
-                  
-                </div>
-              </div>
-            </div>
-            <!-- ENDS CONTENT SECTION -->
-          </div>
-          <!-- ENDS .content -->
-        </div>
-      </div>
-      <footer>
-  <div class="container">
-    <div class="row">
-      <div class="col-xs-12">
-          
-              <p class="copyright">Apache Mynewt is available under Apache License, version 2.0.</p>
-          
-      </div>
-      <div class="col-xs-12">
-          <div class="logos">
-              <img src="../../_static/img/asf_logo_wide_small.png" alt="Apache" title="Apache">
-              <small class="footnote">
-                Apache Mynewt, Mynewt, Apache, the Apache feather logo, and the Apache Mynewt project logo are either
-                registered trademarks or trademarks of the Apache Software Foundation in the United States and other countries.
-              </small>
-              <a href="https://join.slack.com/mynewt/shared_invite/MTkwMTg1ODM1NTg5LTE0OTYxNzQ4NzQtZTU1YmNhYjhkMg">
-                <img src="../../_static/img/add_to_slack.png" alt="Slack Icon" title="Join our Slack Community" />
-              </a>
-          </div>
-      </div>
-    </div>
-  </div>
-</footer>
-    </div>
-    <!-- ENDS #wrapper -->
-
-  
-
-    <script type="text/javascript">
-        var DOCUMENTATION_OPTIONS = {
-            URL_ROOT:'../../',
-            VERSION:'1.3.0',
-            COLLAPSE_INDEX:false,
-            FILE_SUFFIX:'.html',
-            HAS_SOURCE:  true,
-            SOURCELINK_SUFFIX: '.txt'
-        };
-    </script>
-      <script type="text/javascript" src="../../_static/jquery.js"></script>
-      <script type="text/javascript" src="../../_static/underscore.js"></script>
-      <script type="text/javascript" src="../../_static/doctools.js"></script>
-      <script type="text/javascript" src="../../_static/js/bootstrap-3.0.3.min.js"></script>
-      <script type="text/javascript" src="../../_static/js/affix.js"></script>
-      <script type="text/javascript" src="../../_static/js/main.js"></script>
-
-   
-
-  </body>
-</html>
\ No newline at end of file
diff --git a/develop/searchindex.js b/develop/searchindex.js
index 11fd76cbd..b10faba57 100644
--- a/develop/searchindex.js
+++ b/develop/searchindex.js
@@ -1 +1 @@
-Search.setIndex({docnames:["_static/common","concepts","get_started/docker","get_started/index","get_started/native_install/cross_tools","get_started/native_install/index","get_started/native_install/native_tools","get_started/project_create","get_started/serial_access","index","misc/faq","misc/go_env","misc/ide","misc/index","network/ble/ble_hs/ble_att","network/ble/ble_hs/ble_gap","network/ble/ble_hs/ble_gattc","network/ble/ble_hs/ble_gatts","network/ble/ble_hs/ble_hs","network/ble/ble_hs/ble_hs_id","network/ble/ble_hs/ble_hs_return_codes","network/ble/ble_intro","network/ble/ble_sec","network/ble/ble_setup/ble_addr","network/ble/ble_setup/ble_lp_clock","network/ble/ble_setup/ble_setup_intro","network/ble/ble_setup/ble_sync_cb","network/ble/btshell/btshell_GAP","network/ble/btshell/btshell_GATT","network/ble/btshell/btshell_advdata","network/ble/btshell/btshell_api","network/ble/mesh/index","network/ble/mesh/sample","newt/README","newt/command_list/newt_build","newt/command_list/newt_clean","newt/command_list/newt_complete","newt/command_list/newt_create_image","newt/command_list/newt_debug","newt/command_list/newt_help","newt/command_list/newt_info","newt/command_list/newt_install","newt/command_list/newt_load","newt/command_list/newt_mfg","newt/command_list/newt_new","newt/command_list/newt_pkg","newt/command_list/newt_resign_image","newt/command_list/newt_run","newt/command_list/newt_size","newt/command_list/newt_sync","newt/command_list/newt_target","newt/command_list/newt_test","newt/command_list/newt_upgrade","newt/command_list/newt_vals","newt/command_list/newt_version","newt/index","newt/install/index","newt/install/newt_linux","newt/install/newt_mac","newt/install/newt_windows","newt/install/prev_releases","newt/newt_operation","newt/newt_ops","newtmgr/README","newtmgr/command_list/index","newtmgr/command_list/newtmgr_config","newtmgr/command_list/newtmgr_conn","newtmgr/command_list/newtmgr_crash","newtmgr/command_list/newtmgr_datetime","newtmgr/command_list/newtmgr_echo","newtmgr/command_list/newtmgr_fs","newtmgr/command_list/newtmgr_image","newtmgr/command_list/newtmgr_logs","newtmgr/command_list/newtmgr_mpstats","newtmgr/command_list/newtmgr_reset","newtmgr/command_list/newtmgr_run","newtmgr/command_list/newtmgr_stat","newtmgr/command_list/newtmgr_taskstats","newtmgr/index","newtmgr/install/index","newtmgr/install/install_linux","newtmgr/install/install_mac","newtmgr/install/install_windows","newtmgr/install/prev_releases","os/core_os/API","os/core_os/callout/callout","os/core_os/context_switch/context_switch","os/core_os/cputime/os_cputime","os/core_os/event_queue/event_queue","os/core_os/heap/heap","os/core_os/mbuf/mbuf","os/core_os/memory_pool/memory_pool","os/core_os/mqueue/mqueue","os/core_os/msys/msys","os/core_os/mutex/mutex","os/core_os/mynewt_os","os/core_os/os_init","os/core_os/os_start","os/core_os/os_started","os/core_os/porting/port_bsp","os/core_os/porting/port_cpu","os/core_os/porting/port_mcu","os/core_os/porting/port_os","os/core_os/sanity/sanity","os/core_os/semaphore/semaphore","os/core_os/task/task","os/core_os/time/os_time","os/modules/baselibc","os/modules/bootloader/boot_build_status","os/modules/bootloader/boot_build_status_one","os/modules/bootloader/boot_clear_status","os/modules/bootloader/boot_copy_area","os/modules/bootloader/boot_copy_image","os/modules/bootloader/boot_erase_area","os/modules/bootloader/boot_fill_slot","os/modules/bootloader/boot_find_image_area_idx","os/modules/bootloader/boot_find_image_part","os/modules/bootloader/boot_find_image_slot","os/modules/bootloader/boot_go","os/modules/bootloader/boot_init_flash","os/modules/bootloader/boot_move_area","os/modules/bootloader/boot_read_image_header","os/modules/bootloader/boot_read_image_headers","os/modules/bootloader/boot_read_status","os/modules/bootloader/boot_select_image_slot","os/modules/bootloader/boot_slot_addr","os/modules/bootloader/boot_slot_to_area_idx","os/modules/bootloader/boot_swap_areas","os/modules/bootloader/boot_vect_delete_main","os/modules/bootloader/boot_vect_delete_test","os/modules/bootloader/boot_vect_read_main","os/modules/bootloader/boot_vect_read_one","os/modules/bootloader/boot_vect_read_test","os/modules/bootloader/boot_write_status","os/modules/bootloader/bootloader","os/modules/config/config","os/modules/console/console","os/modules/devmgmt/customize_newtmgr","os/modules/devmgmt/newtmgr","os/modules/devmgmt/oicmgr","os/modules/drivers/driver","os/modules/drivers/flash","os/modules/drivers/mmc","os/modules/elua/elua","os/modules/elua/lua_init","os/modules/elua/lua_main","os/modules/fcb/fcb","os/modules/fcb/fcb_append","os/modules/fcb/fcb_append_finish","os/modules/fcb/fcb_append_to_scratch","os/modules/fcb/fcb_clear","os/modules/fcb/fcb_getnext","os/modules/fcb/fcb_init","os/modules/fcb/fcb_is_empty","os/modules/fcb/fcb_offset_last_n","os/modules/fcb/fcb_rotate","os/modules/fcb/fcb_walk","os/modules/fs/fatfs","os/modules/fs/fs/fs","os/modules/fs/fs/fs_close","os/modules/fs/fs/fs_closedir","os/modules/fs/fs/fs_dirent_is_dir","os/modules/fs/fs/fs_dirent_name","os/modules/fs/fs/fs_filelen","os/modules/fs/fs/fs_getpos","os/modules/fs/fs/fs_mkdir","os/modules/fs/fs/fs_open","os/modules/fs/fs/fs_opendir","os/modules/fs/fs/fs_ops","os/modules/fs/fs/fs_read","os/modules/fs/fs/fs_readdir","os/modules/fs/fs/fs_register","os/modules/fs/fs/fs_rename","os/modules/fs/fs/fs_return_codes","os/modules/fs/fs/fs_seek","os/modules/fs/fs/fs_unlink","os/modules/fs/fs/fs_write","os/modules/fs/fs/fsutil_read_file","os/modules/fs/fs/fsutil_write_file","os/modules/fs/nffs/nffs","os/modules/fs/nffs/nffs_area_desc","os/modules/fs/nffs/nffs_config","os/modules/fs/nffs/nffs_detect","os/modules/fs/nffs/nffs_format","os/modules/fs/nffs/nffs_init","os/modules/fs/nffs/nffs_internals","os/modules/fs/otherfs","os/modules/hal/hal","os/modules/hal/hal_api","os/modules/hal/hal_bsp/hal_bsp","os/modules/hal/hal_creation","os/modules/hal/hal_flash/hal_flash","os/modules/hal/hal_flash/hal_flash_int","os/modules/hal/hal_gpio/hal_gpio","os/modules/hal/hal_i2c/hal_i2c","os/modules/hal/hal_in_libraries","os/modules/hal/hal_os_tick/hal_os_tick","os/modules/hal/hal_spi/hal_spi","os/modules/hal/hal_system/hal_sys","os/modules/hal/hal_timer/hal_timer","os/modules/hal/hal_uart/hal_uart","os/modules/hal/hal_watchdog/hal_watchdog","os/modules/imgmgr/imgmgr","os/modules/imgmgr/imgmgr_module_init","os/modules/imgmgr/imgr_ver_parse","os/modules/imgmgr/imgr_ver_str","os/modules/json/json","os/modules/json/json_encode_object_entry","os/modules/json/json_encode_object_finish","os/modules/json/json_encode_object_key","os/modules/json/json_encode_object_start","os/modules/json/json_read_object","os/modules/logs/logs","os/modules/sensor_framework/sensor_api","os/modules/sensor_framework/sensor_create","os/modules/sensor_framework/sensor_driver","os/modules/sensor_framework/sensor_framework_overview","os/modules/sensor_framework/sensor_listener_api","os/modules/sensor_framework/sensor_mgr_api","os/modules/sensor_framework/sensor_oic","os/modules/sensor_framework/sensor_shell","os/modules/shell/shell","os/modules/shell/shell_cmd_register","os/modules/shell/shell_evq_set","os/modules/shell/shell_nlip_input_register","os/modules/shell/shell_nlip_output","os/modules/shell/shell_register","os/modules/shell/shell_register_app_cmd_handler","os/modules/shell/shell_register_default_module","os/modules/split/split","os/modules/stats/stats","os/modules/sysinitconfig/sysconfig_error","os/modules/sysinitconfig/sysinitconfig","os/modules/testutil/test_assert","os/modules/testutil/test_case","os/modules/testutil/test_decl","os/modules/testutil/test_pass","os/modules/testutil/test_suite","os/modules/testutil/testutil","os/modules/testutil/tu_init","os/modules/testutil/tu_restart","os/os_user_guide","os/tutorials/STM32F303","os/tutorials/add_newtmgr","os/tutorials/codesize","os/tutorials/define_target","os/tutorials/event_queue","os/tutorials/ota_upgrade_nrf52","os/tutorials/pin-wheel-mods","os/tutorials/segger_rtt","os/tutorials/segger_sysview","os/tutorials/tasks_lesson","os/tutorials/try_markdown","os/tutorials/unit_test","os/tutorials/wi-fi_on_arduino","tutorials/ble/ble","tutorials/ble/ble_bare_bones","tutorials/ble/blehci_project","tutorials/ble/bleprph/bleprph","tutorials/ble/bleprph/bleprph-sections/bleprph-adv","tutorials/ble/bleprph/bleprph-sections/bleprph-app","tutorials/ble/bleprph/bleprph-sections/bleprph-chr-access","tutorials/ble/bleprph/bleprph-sections/bleprph-gap-event","tutorials/ble/bleprph/bleprph-sections/bleprph-svc-reg","tutorials/ble/eddystone","tutorials/ble/ibeacon","tutorials/blinky/arduino_zero","tutorials/blinky/blinky","tutorials/blinky/blinky_console","tutorials/blinky/blinky_primo","tutorials/blinky/blinky_stm32f4disc","tutorials/blinky/nRF52","tutorials/blinky/olimex","tutorials/blinky/rbnano2","tutorials/lora/lorawanapp","tutorials/other/codesize","tutorials/other/other","tutorials/other/unit_test","tutorials/other/wi-fi_on_arduino","tutorials/repo/add_repos","tutorials/repo/create_repo","tutorials/repo/private_repo","tutorials/repo/upgrade_repo","tutorials/sensors/air_quality","tutorials/sensors/air_quality_ble","tutorials/sensors/air_quality_sensor","tutorials/sensors/nrf52_adc","tutorials/sensors/sensor_bleprph_oic","tutorials/sensors/sensor_nrf52_bno055","tutorials/sensors/sensor_nrf52_bno055_oic","tutorials/sensors/sensor_offboard_config","tutorials/sensors/sensor_oic_overview","tutorials/sensors/sensor_thingy_lis2dh12_onb","tutorials/sensors/sensors","tutorials/sensors/sensors_framework","tutorials/slinky/project-nrf52-slinky","tutorials/slinky/project-sim-slinky","tutorials/slinky/project-slinky","tutorials/slinky/project-stm32-slinky","tutorials/tooling/segger_rtt","tutorials/tooling/segger_sysview","tutorials/tooling/tooling","tutorials/tutorials"],envversion:52,filenames:["_static/common.rst","concepts.rst","get_started/docker.rst","get_started/index.rst","get_started/native_install/cross_tools.rst","get_started/native_install/index.rst","get_started/native_install/native_tools.rst","get_started/project_create.rst","get_started/serial_access.rst","index.rst","misc/faq.rst","misc/go_env.rst","misc/ide.rst","misc/index.rst","network/ble/ble_hs/ble_att.rst","network/ble/ble_hs/ble_gap.rst","network/ble/ble_hs/ble_gattc.rst","network/ble/ble_hs/ble_gatts.rst","network/ble/ble_hs/ble_hs.rst","network/ble/ble_hs/ble_hs_id.rst","network/ble/ble_hs/ble_hs_return_codes.rst","network/ble/ble_intro.rst","network/ble/ble_sec.rst","network/ble/ble_setup/ble_addr.rst","network/ble/ble_setup/ble_lp_clock.rst","network/ble/ble_setup/ble_setup_intro.rst","network/ble/ble_setup/ble_sync_cb.rst","network/ble/btshell/btshell_GAP.rst","network/ble/btshell/btshell_GATT.rst","network/ble/btshell/btshell_advdata.rst","network/ble/btshell/btshell_api.rst","network/ble/mesh/index.rst","network/ble/mesh/sample.rst","newt/README.rst","newt/command_list/newt_build.rst","newt/command_list/newt_clean.rst","newt/command_list/newt_complete.rst","newt/command_list/newt_create_image.rst","newt/command_list/newt_debug.rst","newt/command_list/newt_help.rst","newt/command_list/newt_info.rst","newt/command_list/newt_install.rst","newt/command_list/newt_load.rst","newt/command_list/newt_mfg.rst","newt/command_list/newt_new.rst","newt/command_list/newt_pkg.rst","newt/command_list/newt_resign_image.rst","newt/command_list/newt_run.rst","newt/command_list/newt_size.rst","newt/command_list/newt_sync.rst","newt/command_list/newt_target.rst","newt/command_list/newt_test.rst","newt/command_list/newt_upgrade.rst","newt/command_list/newt_vals.rst","newt/command_list/newt_version.rst","newt/index.rst","newt/install/index.rst","newt/install/newt_linux.rst","newt/install/newt_mac.rst","newt/install/newt_windows.rst","newt/install/prev_releases.rst","newt/newt_operation.rst","newt/newt_ops.rst","newtmgr/README.rst","newtmgr/command_list/index.rst","newtmgr/command_list/newtmgr_config.rst","newtmgr/command_list/newtmgr_conn.rst","newtmgr/command_list/newtmgr_crash.rst","newtmgr/command_list/newtmgr_datetime.rst","newtmgr/command_list/newtmgr_echo.rst","newtmgr/command_list/newtmgr_fs.rst","newtmgr/command_list/newtmgr_image.rst","newtmgr/command_list/newtmgr_logs.rst","newtmgr/command_list/newtmgr_mpstats.rst","newtmgr/command_list/newtmgr_reset.rst","newtmgr/command_list/newtmgr_run.rst","newtmgr/command_list/newtmgr_stat.rst","newtmgr/command_list/newtmgr_taskstats.rst","newtmgr/index.rst","newtmgr/install/index.rst","newtmgr/install/install_linux.rst","newtmgr/install/install_mac.rst","newtmgr/install/install_windows.rst","newtmgr/install/prev_releases.rst","os/core_os/API.rst","os/core_os/callout/callout.rst","os/core_os/context_switch/context_switch.rst","os/core_os/cputime/os_cputime.rst","os/core_os/event_queue/event_queue.rst","os/core_os/heap/heap.rst","os/core_os/mbuf/mbuf.rst","os/core_os/memory_pool/memory_pool.rst","os/core_os/mqueue/mqueue.rst","os/core_os/msys/msys.rst","os/core_os/mutex/mutex.rst","os/core_os/mynewt_os.rst","os/core_os/os_init.rst","os/core_os/os_start.rst","os/core_os/os_started.rst","os/core_os/porting/port_bsp.rst","os/core_os/porting/port_cpu.rst","os/core_os/porting/port_mcu.rst","os/core_os/porting/port_os.rst","os/core_os/sanity/sanity.rst","os/core_os/semaphore/semaphore.rst","os/core_os/task/task.rst","os/core_os/time/os_time.rst","os/modules/baselibc.rst","os/modules/bootloader/boot_build_status.rst","os/modules/bootloader/boot_build_status_one.rst","os/modules/bootloader/boot_clear_status.rst","os/modules/bootloader/boot_copy_area.rst","os/modules/bootloader/boot_copy_image.rst","os/modules/bootloader/boot_erase_area.rst","os/modules/bootloader/boot_fill_slot.rst","os/modules/bootloader/boot_find_image_area_idx.rst","os/modules/bootloader/boot_find_image_part.rst","os/modules/bootloader/boot_find_image_slot.rst","os/modules/bootloader/boot_go.rst","os/modules/bootloader/boot_init_flash.rst","os/modules/bootloader/boot_move_area.rst","os/modules/bootloader/boot_read_image_header.rst","os/modules/bootloader/boot_read_image_headers.rst","os/modules/bootloader/boot_read_status.rst","os/modules/bootloader/boot_select_image_slot.rst","os/modules/bootloader/boot_slot_addr.rst","os/modules/bootloader/boot_slot_to_area_idx.rst","os/modules/bootloader/boot_swap_areas.rst","os/modules/bootloader/boot_vect_delete_main.rst","os/modules/bootloader/boot_vect_delete_test.rst","os/modules/bootloader/boot_vect_read_main.rst","os/modules/bootloader/boot_vect_read_one.rst","os/modules/bootloader/boot_vect_read_test.rst","os/modules/bootloader/boot_write_status.rst","os/modules/bootloader/bootloader.rst","os/modules/config/config.rst","os/modules/console/console.rst","os/modules/devmgmt/customize_newtmgr.rst","os/modules/devmgmt/newtmgr.rst","os/modules/devmgmt/oicmgr.rst","os/modules/drivers/driver.rst","os/modules/drivers/flash.rst","os/modules/drivers/mmc.rst","os/modules/elua/elua.rst","os/modules/elua/lua_init.rst","os/modules/elua/lua_main.rst","os/modules/fcb/fcb.rst","os/modules/fcb/fcb_append.rst","os/modules/fcb/fcb_append_finish.rst","os/modules/fcb/fcb_append_to_scratch.rst","os/modules/fcb/fcb_clear.rst","os/modules/fcb/fcb_getnext.rst","os/modules/fcb/fcb_init.rst","os/modules/fcb/fcb_is_empty.rst","os/modules/fcb/fcb_offset_last_n.rst","os/modules/fcb/fcb_rotate.rst","os/modules/fcb/fcb_walk.rst","os/modules/fs/fatfs.rst","os/modules/fs/fs/fs.rst","os/modules/fs/fs/fs_close.rst","os/modules/fs/fs/fs_closedir.rst","os/modules/fs/fs/fs_dirent_is_dir.rst","os/modules/fs/fs/fs_dirent_name.rst","os/modules/fs/fs/fs_filelen.rst","os/modules/fs/fs/fs_getpos.rst","os/modules/fs/fs/fs_mkdir.rst","os/modules/fs/fs/fs_open.rst","os/modules/fs/fs/fs_opendir.rst","os/modules/fs/fs/fs_ops.rst","os/modules/fs/fs/fs_read.rst","os/modules/fs/fs/fs_readdir.rst","os/modules/fs/fs/fs_register.rst","os/modules/fs/fs/fs_rename.rst","os/modules/fs/fs/fs_return_codes.rst","os/modules/fs/fs/fs_seek.rst","os/modules/fs/fs/fs_unlink.rst","os/modules/fs/fs/fs_write.rst","os/modules/fs/fs/fsutil_read_file.rst","os/modules/fs/fs/fsutil_write_file.rst","os/modules/fs/nffs/nffs.rst","os/modules/fs/nffs/nffs_area_desc.rst","os/modules/fs/nffs/nffs_config.rst","os/modules/fs/nffs/nffs_detect.rst","os/modules/fs/nffs/nffs_format.rst","os/modules/fs/nffs/nffs_init.rst","os/modules/fs/nffs/nffs_internals.rst","os/modules/fs/otherfs.rst","os/modules/hal/hal.rst","os/modules/hal/hal_api.rst","os/modules/hal/hal_bsp/hal_bsp.rst","os/modules/hal/hal_creation.rst","os/modules/hal/hal_flash/hal_flash.rst","os/modules/hal/hal_flash/hal_flash_int.rst","os/modules/hal/hal_gpio/hal_gpio.rst","os/modules/hal/hal_i2c/hal_i2c.rst","os/modules/hal/hal_in_libraries.rst","os/modules/hal/hal_os_tick/hal_os_tick.rst","os/modules/hal/hal_spi/hal_spi.rst","os/modules/hal/hal_system/hal_sys.rst","os/modules/hal/hal_timer/hal_timer.rst","os/modules/hal/hal_uart/hal_uart.rst","os/modules/hal/hal_watchdog/hal_watchdog.rst","os/modules/imgmgr/imgmgr.rst","os/modules/imgmgr/imgmgr_module_init.rst","os/modules/imgmgr/imgr_ver_parse.rst","os/modules/imgmgr/imgr_ver_str.rst","os/modules/json/json.rst","os/modules/json/json_encode_object_entry.rst","os/modules/json/json_encode_object_finish.rst","os/modules/json/json_encode_object_key.rst","os/modules/json/json_encode_object_start.rst","os/modules/json/json_read_object.rst","os/modules/logs/logs.rst","os/modules/sensor_framework/sensor_api.rst","os/modules/sensor_framework/sensor_create.rst","os/modules/sensor_framework/sensor_driver.rst","os/modules/sensor_framework/sensor_framework_overview.rst","os/modules/sensor_framework/sensor_listener_api.rst","os/modules/sensor_framework/sensor_mgr_api.rst","os/modules/sensor_framework/sensor_oic.rst","os/modules/sensor_framework/sensor_shell.rst","os/modules/shell/shell.rst","os/modules/shell/shell_cmd_register.rst","os/modules/shell/shell_evq_set.rst","os/modules/shell/shell_nlip_input_register.rst","os/modules/shell/shell_nlip_output.rst","os/modules/shell/shell_register.rst","os/modules/shell/shell_register_app_cmd_handler.rst","os/modules/shell/shell_register_default_module.rst","os/modules/split/split.rst","os/modules/stats/stats.rst","os/modules/sysinitconfig/sysconfig_error.rst","os/modules/sysinitconfig/sysinitconfig.rst","os/modules/testutil/test_assert.rst","os/modules/testutil/test_case.rst","os/modules/testutil/test_decl.rst","os/modules/testutil/test_pass.rst","os/modules/testutil/test_suite.rst","os/modules/testutil/testutil.rst","os/modules/testutil/tu_init.rst","os/modules/testutil/tu_restart.rst","os/os_user_guide.rst","os/tutorials/STM32F303.rst","os/tutorials/add_newtmgr.rst","os/tutorials/codesize.rst","os/tutorials/define_target.rst","os/tutorials/event_queue.rst","os/tutorials/ota_upgrade_nrf52.rst","os/tutorials/pin-wheel-mods.rst","os/tutorials/segger_rtt.rst","os/tutorials/segger_sysview.rst","os/tutorials/tasks_lesson.rst","os/tutorials/try_markdown.rst","os/tutorials/unit_test.rst","os/tutorials/wi-fi_on_arduino.rst","tutorials/ble/ble.rst","tutorials/ble/ble_bare_bones.rst","tutorials/ble/blehci_project.rst","tutorials/ble/bleprph/bleprph.rst","tutorials/ble/bleprph/bleprph-sections/bleprph-adv.rst","tutorials/ble/bleprph/bleprph-sections/bleprph-app.rst","tutorials/ble/bleprph/bleprph-sections/bleprph-chr-access.rst","tutorials/ble/bleprph/bleprph-sections/bleprph-gap-event.rst","tutorials/ble/bleprph/bleprph-sections/bleprph-svc-reg.rst","tutorials/ble/eddystone.rst","tutorials/ble/ibeacon.rst","tutorials/blinky/arduino_zero.rst","tutorials/blinky/blinky.rst","tutorials/blinky/blinky_console.rst","tutorials/blinky/blinky_primo.rst","tutorials/blinky/blinky_stm32f4disc.rst","tutorials/blinky/nRF52.rst","tutorials/blinky/olimex.rst","tutorials/blinky/rbnano2.rst","tutorials/lora/lorawanapp.rst","tutorials/other/codesize.rst","tutorials/other/other.rst","tutorials/other/unit_test.rst","tutorials/other/wi-fi_on_arduino.rst","tutorials/repo/add_repos.rst","tutorials/repo/create_repo.rst","tutorials/repo/private_repo.rst","tutorials/repo/upgrade_repo.rst","tutorials/sensors/air_quality.rst","tutorials/sensors/air_quality_ble.rst","tutorials/sensors/air_quality_sensor.rst","tutorials/sensors/nrf52_adc.rst","tutorials/sensors/sensor_bleprph_oic.rst","tutorials/sensors/sensor_nrf52_bno055.rst","tutorials/sensors/sensor_nrf52_bno055_oic.rst","tutorials/sensors/sensor_offboard_config.rst","tutorials/sensors/sensor_oic_overview.rst","tutorials/sensors/sensor_thingy_lis2dh12_onb.rst","tutorials/sensors/sensors.rst","tutorials/sensors/sensors_framework.rst","tutorials/slinky/project-nrf52-slinky.rst","tutorials/slinky/project-sim-slinky.rst","tutorials/slinky/project-slinky.rst","tutorials/slinky/project-stm32-slinky.rst","tutorials/tooling/segger_rtt.rst","tutorials/tooling/segger_sysview.rst","tutorials/tooling/tooling.rst","tutorials/tutorials.rst"],objects:{"":{"os_task::SLIST_ENTRY":[84,2,1,"c.os_task::SLIST_ENTRY"],"os_task::STAILQ_ENTRY":[84,2,1,"c.os_task::STAILQ_ENTRY"],"os_task::TAILQ_ENTRY":[84,2,1,"c.os_task::TAILQ_ENTRY"],"os_task::t_arg":[84,5,1,"c.os_task::t_arg"],"os_task::t_ctx_sw_cnt":[84,5,1,"c.os_task::t_ctx_sw_cnt"],"os_task::t_flags":[84,5,1,"c.os_task::t_flags"],"os_task::t_func":[84,5,1,"c.os_task::t_func"],"os_task::t_lockcnt":[84,5,1,"c.os_task::t_lockcnt"],"os_task::t_name":[84,5,1,"c.os_task::t_name"],"os_task::t_next_wakeup":[84,5,1,"c.os_task::t_next_wakeup"],"os_task::t_obj":[84,5,1,"c.os_task::t_obj"],"os_task::t_pad":[84,5,1,"c.os_task::t_pad"],"os_task::t_prio":[84,5,1,"c.os_task::t_prio"],"os_task::t_run_time":[84,5,1,"c.os_task::t_run_time"],"os_task::t_sanity_check":[84,5,1,"c.os_task::t_sanity_check"],"os_task::t_stackptr":[84,5,1,"c.os_task::t_stackptr"],"os_task::t_stacksize":[84,5,1,"c.os_task::t_stacksize"],"os_task::t_stacktop":[84,5,1,"c.os_task::t_stacktop"],"os_task::t_state":[84,5,1,"c.os_task::t_state"],"os_task::t_taskid":[84,5,1,"c.os_task::t_taskid"],"os_task_info::oti_cswcnt":[84,5,1,"c.os_task_info::oti_cswcnt"],"os_task_info::oti_last_checkin":[84,5,1,"c.os_task_info::oti_last_checkin"],"os_task_info::oti_next_checkin":[84,5,1,"c.os_task_info::oti_next_checkin"],"os_task_info::oti_prio":[84,5,1,"c.os_task_info::oti_prio"],"os_task_info::oti_runtime":[84,5,1,"c.os_task_info::oti_runtime"],"os_task_info::oti_state":[84,5,1,"c.os_task_info::oti_state"],"os_task_info::oti_stksize":[84,5,1,"c.os_task_info::oti_stksize"],"os_task_info::oti_stkusage":[84,5,1,"c.os_task_info::oti_stkusage"],"os_task_info::oti_taskid":[84,5,1,"c.os_task_info::oti_taskid"],"os_task_obj::SLIST_HEAD":[84,2,1,"c.os_task_obj::SLIST_HEAD"],"os_timeval::tv_sec":[84,5,1,"c.os_timeval::tv_sec"],"os_timeval::tv_usec":[84,5,1,"c.os_timeval::tv_usec"],"os_timezone::tz_dsttime":[84,5,1,"c.os_timezone::tz_dsttime"],"os_timezone::tz_minuteswest":[84,5,1,"c.os_timezone::tz_minuteswest"],CPUTIME_GEQ:[84,0,1,"c.CPUTIME_GEQ"],CPUTIME_GT:[84,0,1,"c.CPUTIME_GT"],CPUTIME_LEQ:[84,0,1,"c.CPUTIME_LEQ"],CPUTIME_LT:[84,0,1,"c.CPUTIME_LT"],CTASSERT:[84,0,1,"c.CTASSERT"],OS_ALIGN:[84,0,1,"c.OS_ALIGN"],OS_IDLE_PRIO:[84,0,1,"c.OS_IDLE_PRIO"],OS_MAIN_STACK_SIZE:[84,0,1,"c.OS_MAIN_STACK_SIZE"],OS_MAIN_TASK_PRIO:[84,0,1,"c.OS_MAIN_TASK_PRIO"],OS_TASK_FLAG_EVQ_WAIT:[84,0,1,"c.OS_TASK_FLAG_EVQ_WAIT"],OS_TASK_FLAG_MUTEX_WAIT:[84,0,1,"c.OS_TASK_FLAG_MUTEX_WAIT"],OS_TASK_FLAG_NO_TIMEOUT:[84,0,1,"c.OS_TASK_FLAG_NO_TIMEOUT"],OS_TASK_FLAG_SEM_WAIT:[84,0,1,"c.OS_TASK_FLAG_SEM_WAIT"],OS_TASK_MAX_NAME_LEN:[84,0,1,"c.OS_TASK_MAX_NAME_LEN"],OS_TASK_PRI_HIGHEST:[84,0,1,"c.OS_TASK_PRI_HIGHEST"],OS_TASK_PRI_LOWEST:[84,0,1,"c.OS_TASK_PRI_LOWEST"],OS_TASK_READY:[84,1,1,"c.OS_TASK_READY"],OS_TASK_SLEEP:[84,1,1,"c.OS_TASK_SLEEP"],OS_TIMEOUT_NEVER:[84,0,1,"c.OS_TIMEOUT_NEVER"],OS_TIME_MAX:[84,0,1,"c.OS_TIME_MAX"],OS_TIME_TICK_GEQ:[84,0,1,"c.OS_TIME_TICK_GEQ"],OS_TIME_TICK_GT:[84,0,1,"c.OS_TIME_TICK_GT"],OS_TIME_TICK_LT:[84,0,1,"c.OS_TIME_TICK_LT"],OS_WAIT_FOREVER:[84,0,1,"c.OS_WAIT_FOREVER"],STAILQ_HEAD:[84,2,1,"c.STAILQ_HEAD"],TAILQ_HEAD:[84,2,1,"c.TAILQ_HEAD"],completion_cb:[136,3,1,"c.completion_cb"],console_append_char_cb:[136,3,1,"c.console_append_char_cb"],console_blocking_mode:[136,2,1,"c.console_blocking_mode"],console_echo:[136,2,1,"c.console_echo"],console_handle_char:[136,2,1,"c.console_handle_char"],console_init:[136,2,1,"c.console_init"],console_input:[136,4,1,"c.console_input"],console_is_init:[136,2,1,"c.console_is_init"],console_is_midline:[136,5,1,"c.console_is_midline"],console_non_blocking_mode:[136,2,1,"c.console_non_blocking_mode"],console_out:[136,2,1,"c.console_out"],console_printf:[136,2,1,"c.console_printf"],console_read:[136,2,1,"c.console_read"],console_rx_cb:[136,3,1,"c.console_rx_cb"],console_set_completion_cb:[136,2,1,"c.console_set_completion_cb"],console_set_queues:[136,2,1,"c.console_set_queues"],console_write:[136,2,1,"c.console_write"],g_current_task:[84,5,1,"c.g_current_task"],g_os_run_list:[84,5,1,"c.g_os_run_list"],g_os_sleep_list:[84,5,1,"c.g_os_sleep_list"],g_os_started:[84,5,1,"c.g_os_started"],g_os_task_list:[84,5,1,"c.g_os_task_list"],os_cputime_delay_nsecs:[84,2,1,"c.os_cputime_delay_nsecs"],os_cputime_delay_ticks:[84,2,1,"c.os_cputime_delay_ticks"],os_cputime_delay_usecs:[84,2,1,"c.os_cputime_delay_usecs"],os_cputime_get32:[84,2,1,"c.os_cputime_get32"],os_cputime_init:[84,2,1,"c.os_cputime_init"],os_cputime_nsecs_to_ticks:[84,2,1,"c.os_cputime_nsecs_to_ticks"],os_cputime_ticks_to_nsecs:[84,2,1,"c.os_cputime_ticks_to_nsecs"],os_cputime_ticks_to_usecs:[84,2,1,"c.os_cputime_ticks_to_usecs"],os_cputime_timer_init:[84,2,1,"c.os_cputime_timer_init"],os_cputime_timer_relative:[84,2,1,"c.os_cputime_timer_relative"],os_cputime_timer_start:[84,2,1,"c.os_cputime_timer_start"],os_cputime_timer_stop:[84,2,1,"c.os_cputime_timer_stop"],os_cputime_usecs_to_ticks:[84,2,1,"c.os_cputime_usecs_to_ticks"],os_get_return_addr:[84,0,1,"c.os_get_return_addr"],os_get_uptime_usec:[84,2,1,"c.os_get_uptime_usec"],os_gettimeofday:[84,2,1,"c.os_gettimeofday"],os_info_init:[84,2,1,"c.os_info_init"],os_init:[84,2,1,"c.os_init"],os_init_idle_task:[84,2,1,"c.os_init_idle_task"],os_sched:[84,2,1,"c.os_sched"],os_sched_ctx_sw_hook:[84,2,1,"c.os_sched_ctx_sw_hook"],os_sched_get_current_task:[84,2,1,"c.os_sched_get_current_task"],os_sched_insert:[84,2,1,"c.os_sched_insert"],os_sched_next_task:[84,2,1,"c.os_sched_next_task"],os_sched_os_timer_exp:[84,2,1,"c.os_sched_os_timer_exp"],os_sched_remove:[84,2,1,"c.os_sched_remove"],os_sched_resort:[84,2,1,"c.os_sched_resort"],os_sched_set_current_task:[84,2,1,"c.os_sched_set_current_task"],os_sched_sleep:[84,2,1,"c.os_sched_sleep"],os_sched_wakeup:[84,2,1,"c.os_sched_wakeup"],os_sched_wakeup_ticks:[84,2,1,"c.os_sched_wakeup_ticks"],os_settimeofday:[84,2,1,"c.os_settimeofday"],os_start:[84,2,1,"c.os_start"],os_started:[84,2,1,"c.os_started"],os_stime_t:[84,3,1,"c.os_stime_t"],os_task:[84,4,1,"c.os_task"],os_task_count:[84,2,1,"c.os_task_count"],os_task_func_t:[84,3,1,"c.os_task_func_t"],os_task_info:[84,4,1,"c.os_task_info"],os_task_info_get_next:[84,2,1,"c.os_task_info_get_next"],os_task_init:[84,2,1,"c.os_task_init"],os_task_obj:[84,4,1,"c.os_task_obj"],os_task_remove:[84,2,1,"c.os_task_remove"],os_task_state:[84,6,1,"c.os_task_state"],os_task_state_t:[84,3,1,"c.os_task_state_t"],os_time_advance:[84,2,1,"c.os_time_advance"],os_time_delay:[84,2,1,"c.os_time_delay"],os_time_get:[84,2,1,"c.os_time_get"],os_time_ms_to_ticks:[84,2,1,"c.os_time_ms_to_ticks"],os_time_t:[84,3,1,"c.os_time_t"],os_timeradd:[84,0,1,"c.os_timeradd"],os_timersub:[84,0,1,"c.os_timersub"],os_timeval:[84,4,1,"c.os_timeval"],os_timezone:[84,4,1,"c.os_timezone"]}},objnames:{"0":["c","define","define"],"1":["c","enumvalue","enumvalue"],"2":["c","function","C function"],"3":["c","typedef","typedef"],"4":["c","struct","struct"],"5":["c","variable","variable"],"6":["c","enum","enum"]},objtypes:{"0":"c:define","1":"c:enumvalue","2":"c:function","3":"c:typedef","4":"c:struct","5":"c:variable","6":"c:enum"},terms:{"000s":[269,271,274,286],"008s":[269,271,274,286],"00z":[253,277],"01t22":68,"02t22":[253,277],"04x":20,"05t02":[253,277],"093s":[269,271,274,286],"0b1000110":194,"0mb":11,"0ubuntu5":6,"0x0":[266,273,286],"0x00":[20,273,274,285],"0x0000":[257,285],"0x00000000":[185,229,231,232],"0x00000001":134,"0x00000002":[134,273],"0x00000004":134,"0x00000008":134,"0x00000010":134,"0x000000b8":266,"0x000000d8":[249,250,299,300],"0x000000dc":[249,250,256,292,299,300],"0x00004000":[229,231,232],"0x00008000":[99,229,231,232],"0x00009ef4":273,"0x0000fca6":266,"0x00023800":229,"0x0003f000":229,"0x0003f800":229,"0x0006":29,"0x0007d000":232,"0x000e0000":231,"0x0010":27,"0x01":[20,27,30,134,274],"0x0100":27,"0x01000000":272,"0x0101":20,"0x0102":20,"0x0103":20,"0x0104":20,"0x0105":20,"0x0106":20,"0x0107":20,"0x0108":20,"0x0109":20,"0x010a":20,"0x010b":20,"0x010c":20,"0x010d":20,"0x010e":20,"0x010f":20,"0x0110":20,"0x0111":20,"0x02":[20,27,30,134,274,285],"0x0201":20,"0x0202":20,"0x0203":20,"0x0204":20,"0x0205":20,"0x0206":20,"0x0207":20,"0x0208":20,"0x0209":20,"0x020a":20,"0x020b":20,"0x020c":20,"0x020d":20,"0x020e":20,"0x020f":20,"0x0210":20,"0x0211":20,"0x0212":20,"0x0213":20,"0x0214":20,"0x0215":20,"0x0216":20,"0x0217":20,"0x0218":20,"0x0219":20,"0x021a":20,"0x021b":20,"0x021c":20,"0x021d":20,"0x021e":20,"0x021f":20,"0x0220":20,"0x0221":20,"0x0222":20,"0x0223":20,"0x0224":20,"0x0225":20,"0x0226":20,"0x0227":20,"0x0228":20,"0x0229":20,"0x022a":20,"0x022c":20,"0x022d":20,"0x022e":20,"0x022f":20,"0x0230":20,"0x0232":20,"0x0234":20,"0x0235":20,"0x0236":20,"0x0237":20,"0x0238":20,"0x0239":20,"0x023a":20,"0x023b":20,"0x023c":20,"0x023d":20,"0x023e":20,"0x023f":20,"0x0240":20,"0x03":[20,30,134],"0x0300":[20,27],"0x0301":20,"0x0302":20,"0x04":[20,27],"0x0401":20,"0x0402":20,"0x0403":20,"0x0404":20,"0x0405":20,"0x0406":20,"0x0407":20,"0x0408":20,"0x0409":20,"0x040a":20,"0x040b":20,"0x040c":20,"0x040d":20,"0x040e":20,"0x0483":270,"0x05":20,"0x0501":20,"0x0502":20,"0x0503":20,"0x0504":20,"0x0505":20,"0x0506":20,"0x0507":20,"0x0508":20,"0x0509":20,"0x050a":20,"0x050b":20,"0x050c":20,"0x050d":20,"0x050e":20,"0x06":[20,257],"0x07":20,"0x08":[20,27,285],"0x08000000":272,"0x08000020":272,"0x08000250":272,"0x08021e90":270,"0x09":20,"0x0a":20,"0x0b":20,"0x0bc11477":266,"0x0c":20,"0x0c80":29,"0x0d":20,"0x0e":20,"0x0f":[20,288],"0x0f505235":134,"0x0fffffff":185,"0x1":[286,288,290,292],"0x10":[20,266,273,274,288],"0x100":20,"0x1000":[90,288,290],"0x10000":99,"0x10000000":185,"0x10010000":272,"0x10036413":272,"0x10076413":270,"0x1010":90,"0x103":20,"0x11":[20,23,265,274],"0x12":20,"0x13":20,"0x14":20,"0x1400":285,"0x15":[20,284,286,288],"0x16":20,"0x17":20,"0x18":20,"0x1800":30,"0x1808":30,"0x180a":30,"0x19":[20,214],"0x1a":20,"0x1b":20,"0x1c":[20,284,286],"0x1d":20,"0x1e":20,"0x1f":20,"0x2":[288,290],"0x20":[20,32,99,266,273,284,286],"0x200":[20,288,290],"0x2000":[288,290],"0x20000":286,"0x20000000":99,"0x20002290":270,"0x20002408":266,"0x20008000":266,"0x21":[20,32],"0x21000000":266,"0x22":[20,23,32,274],"0x23":[20,32],"0x24":20,"0x25":[20,285],"0x26":20,"0x27":20,"0x28":20,"0x2800":285,"0x29":20,"0x2a":20,"0x2ba01477":273,"0x2c":20,"0x2d":20,"0x2e":20,"0x2f":20,"0x30":[20,266,273],"0x300":20,"0x311":288,"0x32":[20,288],"0x33":23,"0x34":20,"0x35":20,"0x36":20,"0x37":20,"0x374b":270,"0x38":20,"0x39":20,"0x3a":20,"0x3a000":99,"0x3b":20,"0x3c":20,"0x3c00":285,"0x3d":20,"0x3e":20,"0x3f":20,"0x4":[288,290],"0x40":[20,266,273,284,286],"0x400":20,"0x4000":[288,290],"0x40007000":286,"0x4001e504":273,"0x4001e50c":273,"0x41000000":270,"0x42000":61,"0x44":[23,285],"0x4400":285,"0x46":194,"0x4f":[284,286],"0x50":[266,273],"0x500":20,"0x5000":285,"0x55":23,"0x60":[266,273],"0x61":[284,286],"0x66":23,"0x6c00":285,"0x70":[266,273],"0x72":[284,286],"0x7800":285,"0x7fefd260":134,"0x7fff8000":286,"0x7fffffff":185,"0x80":[284,286],"0x8000":61,"0x8000000":272,"0x80000000":185,"0x8079b62c":134,"0x8801":285,"0x8c":194,"0x8d":194,"0x90":[284,286],"0x96f3b83c":134,"0x9c01":285,"0x9f":285,"0xa0":288,"0xa001":285,"0xa7":[284,286],"0xaf":[284,286],"0xb3":[284,286],"0xb401":285,"0xb5":[284,286],"0xbead":[284,286],"0xcc01":285,"0xd2":[284,286],"0xd801":285,"0xdead":[284,286],"0xe401":285,"0xe7":[284,286],"0xf":285,"0xf001":285,"0xf395c277":134,"0xfb":288,"0xfe":285,"0xff":[134,185],"0xffff":[29,285],"0xfffffffe":185,"0xffffffff":[134,185,213,266],"0xffffffff0xffffffff0xffffffff0xffffffff":273,"100kb":107,"1024kbyte":[270,272],"103kb":229,"10m":27,"110kb":229,"128kb":[9,231],"12c":[269,271,274,286],"12kb":232,"12mhz":9,"132425ssb":30,"132428ssb":30,"132433ssb":30,"132437ssb":30,"132441ssb":30,"14e":[249,299],"14h":[249,292,299],"1503a0":278,"16kb":[9,231,232],"16kbram":53,"16mb":9,"190a192":285,"1_amd64":[57,60,80,83],"1c15":[284,286],"1d11":295,"1d13":[254,278,298],"1d560":229,"1eec4":229,"1kb":229,"1st":68,"1ubuntu1":6,"1wx":273,"200mhz":9,"2015q2":[4,12],"2022609336ssb":260,"2022687456ssb":260,"2022789012ssb":260,"2022851508ssb":260,"2042859320ssb":260,"2042937440ssb":260,"248m":6,"250m":246,"256kb":266,"262s":[269,271,274,286],"28a29":285,"28t22":[253,277],"291ebc02a8c345911c96fdf4e7b9015a843697658fd6b5faa0eb257a23e93682":247,"296712s":272,"2a24":48,"2d5217f":81,"2m_interval_max":27,"2m_interval_min":27,"2m_latenc":27,"2m_max_conn_event_len":27,"2m_min_conn_event_len":27,"2m_scan_interv":27,"2m_scan_window":27,"2m_timeout":27,"2msym":21,"300v":[269,271,274,286],"32kb":[232,266],"32mb":9,"32wx":[266,273],"363s":[269,271,274,286],"3_1":36,"3mb":81,"4_9":4,"4fa7":[284,286],"500m":246,"512kb":99,"575c":229,"5kb":107,"6lowpan":21,"73d77f":71,"78e4d263eeb5af5635705b7cae026cc184f14aa6c6c59c6e80616035cd2efc8f":229,"7b3w9m4n2mg3sqmgw2q1b9p80000gn":55,"7kb":229,"8ab6433f8971b05c2a9c3341533e8ddb754e404":281,"948f118966f7989628f8f3be28840fd23a200fc219bb72acdfe9096f06c4b39b":229,"9cf8af22b1b573909a8290a90c066d4e190407e97680b7a32243960ec2bf3a7f":298,"9mb":58,"abstract":[9,20,101,102,140,157,168,171,179,186,213,215,216,246,285,302],"boolean":[206,232],"break":[20,90,142,240,261,285],"byte":[10,19,23,27,46,66,71,73,90,91,93,105,134,136,138,146,147,159,163,164,166,169,174,175,176,177,178,179,180,185,194,197,206,229,233,247,251,264,265,274],"case":[2,6,7,20,21,30,55,64,65,66,67,68,69,70,71,72,73,74,75,76,77,80,81,82,90,93,95,99,103,104,105,134,140,179,185,190,229,230,232,233,234,235,236,237,238,240,242,250,251,253,254,257,261,262,264,265,266,277,278,284,285,286,300],"catch":20,"char":[84,91,95,103,105,135,136,140,144,145,158,160,161,162,165,166,167,168,170,172,175,177,178,182,183,185,200,204,205,206,207,209,212,221,222,226,227,228,230,232,239,246,251,253,261,264,265,268,277,285,290,292],"class":[140,274],"const":[84,99,134,136,141,158,160,161,162,163,164,165,166,167,168,170,171,172,175,176,177,178,182,183,186,192,206,211,212,215,221,226,228,230,253,261,263,264,265,277,284,285,286],"default":[1,2,4,6,7,10,12,20,24,26,27,28,34,35,37,38,39,40,41,42,43,44,45,46,47,48,49,50,51,52,53,54,57,58,59,61,62,64,65,66,67,68,69,70,71,72,73,74,75,76,77,80,81,82,88,94,95,99,100,102,103,105,136,137,139,140,141,157,181,206,212,213,214,215,216,218,219,220,221,223,228,229,230,231,232,242,243,246,247,249,257,259,261,264,265,266,267,274,279,284,285,286,288,289,291,292,294,299],"enum":[84,135,206,213,284,285],"export":[1,11,23,60,61,80,82,83,88,136,140,142,212,213,214,215,216,243,287,288,290],"final":[8,55,90,94,99,134,148,185,187,208,229,248,251,256,259,284,286],"float":[64,65,66,67,68,69,70,71,72,73,74,75,76,77,80,81,82,107,206,213,287],"function":[1,7,9,14,20,23,31,61,84,85,87,88,89,90,95,96,97,100,101,102,103,105,134,135,136,140,141,142,144,152,156,157,158,159,160,161,162,164,166,167,168,170,172,173,174,175,177,179,180,182,185,186,187,190,193,194,195,196,197,198,199,203,205,207,208,209,210,211,212,214,216,219,221,222,223,224,226,227,229,233,234,235,236,237,239,240,242,243,246,247,249,250,253,256,259,260,262,264,265,267,268,274,277,279,284,285,286,288,292,297,299,300,302],"goto":[103,165,211,215,224,225,284,285,286],"i\u00b2c":194,"import":[11,55,57,80,90,99,106,107,194,251,256,259,262,286],"int":[1,20,26,34,35,37,38,39,40,41,42,43,44,45,46,47,48,49,50,51,52,53,54,57,58,59,62,64,65,66,67,68,69,70,71,72,73,74,75,76,77,80,81,82,84,90,91,92,95,98,103,105,135,136,140,141,142,144,145,147,148,149,150,151,152,153,154,155,156,158,159,160,161,162,163,165,166,167,168,169,170,171,172,174,175,176,177,178,182,183,184,186,190,196,197,201,204,205,206,207,208,209,210,211,214,215,221,222,224,225,226,227,228,230,232,233,234,235,237,238,239,246,248,251,253,259,261,262,263,264,265,268,277,284,285,286,290,292],"long":[3,21,24,28,90,95,104,107,157,175,185,229,273,292],"new":[2,3,4,6,10,11,21,23,24,27,30,31,34,39,41,45,46,50,53,57,58,59,61,84,86,99,102,105,134,136,146,147,148,157,158,167,172,179,182,183,187,202,221,229,230,232,242,247,251,253,254,255,256,257,262,263,264,265,266,269,270,271,272,273,274,277,278,279,285,286,287,289,302],"null":[84,92,93,95,99,103,105,136,141,158,162,166,169,177,179,185,192,211,212,214,215,221,226,228,231,232,246,251,259,262,263,264,265,268,284,285,286,287,290,292],"public":[19,25,27,29,30,32,57,66,80,84,134,136,264,265],"return":[18,26,84,88,90,91,92,93,95,99,103,105,135,136,141,146,158,192,197,206,214,215,218,232,246,251,253,259,261,262,263,266,268,274,277,284,285,286,288,290,292,296],"short":[90,94,221,251],"static":[19,26,66,88,91,95,99,103,135,136,141,145,186,205,207,208,210,211,212,214,215,222,224,225,226,227,228,233,242,246,257,259,261,262,263,264,265,268,284,285,286,287,290,292],"switch":[10,12,20,58,71,77,81,84,86,95,97,99,105,134,187,202,221,243,249,256,257,261,262,284,285,286,292,299],"transient":262,"true":[8,12,84,98,103,106,211,229,233,247,253,277,286,295,298],"try":[2,20,21,23,90,158,185,194,242,248,249,254,256,257,260,266,267,268,269,270,271,273,278,280,286,288,292,294,299],"var":[50,55,65,66,172],"void":[20,26,84,85,88,90,91,92,95,96,97,98,103,105,135,136,140,141,142,144,156,158,159,163,165,166,168,169,172,174,175,176,177,178,184,186,190,196,199,203,205,206,212,214,215,217,222,223,224,226,227,228,232,233,234,235,237,238,239,240,246,251,259,261,262,263,264,265,268,284,285,286,287,290,292],"while":[4,6,7,8,21,23,26,49,55,61,90,91,92,93,95,99,103,105,107,136,142,144,158,160,161,162,167,170,185,200,206,211,215,229,232,233,238,243,244,246,249,250,251,253,264,265,268,275,277,284,285,286,290,292,299,300],AES:22,ANS:258,Adding:[56,79,302],And:[61,134,146,229,231,248,251,255,260,284,285,286],But:286,CTS:257,FOR:4,For:[2,3,5,6,7,8,11,12,20,22,23,24,29,30,34,37,39,50,53,55,57,58,59,60,61,62,66,83,85,88,90,95,99,102,106,107,134,140,141,158,176,179,180,185,186,190,193,194,197,206,212,213,214,215,216,217,227,229,230,231,232,238,240,242,246,247,249,250,253,254,256,261,262,263,264,265,266,268,270,271,272,274,277,278,279,280,285,286,288,290,292,295,298,299,300,302],IDE:[5,12],IDs:134,Its:[100,106,107,242,280],NOT:[90,162,286],Not:[7,20,29,90,92,185,187,229,286],One:[6,20,95,107,185,229,242,254,259,278,285],PCs:8,QoS:[20,21],RTS:257,Such:[185,264,265,280],TMS:266,That:[2,20,61,146,185,232,254,264,265,266,274,278,279,285,286],The:[1,2,3,4,5,6,7,8,10,11,12,14,15,16,17,18,19,20,21,22,23,24,26,27,29,30,31,33,34,37,43,45,46,47,50,55,57,58,59,61,63,64,66,70,71,72,73,75,76,77,78,80,81,82,84,85,86,87,88,89,90,91,92,93,94,95,96,99,100,101,102,103,104,105,106,107,134,135,136,137,138,139,140,141,142,146,158,159,160,161,162,163,164,165,166,167,168,169,170,171,172,174,175,176,178,179,180,181,182,183,185,186,187,188,190,191,192,193,194,196,197,198,199,200,201,202,204,205,206,212,213,214,215,216,217,218,219,220,221,222,224,225,226,227,229,230,231,232,233,236,238,240,241,242,243,244,246,247,248,249,250,251,252,253,254,255,256,257,259,261,262,263,264,265,266,267,269,270,271,272,273,274,275,277,278,279,280,284,285,286,287,288,289,290,291,292,294,295,296,297,298,299,300,302],Then:[10,33,63,134,146,185,229,242,249,253,257,277,285,286,299],There:[4,8,10,22,23,28,57,61,80,85,90,94,99,100,104,105,107,135,136,140,166,185,187,193,212,213,218,221,229,230,249,250,253,261,266,274,277,281,286,292,299,300],These:[5,20,27,50,61,90,99,100,102,104,134,135,140,185,194,213,216,217,218,221,231,243,255,259,263,264,265,266,267,272,279,280,287,288],Use:[1,7,8,11,27,28,50,57,58,59,62,71,80,81,82,99,138,146,148,229,242,254,261,264,265,266,269,274,278,279,286,287,289,297],Used:[94,99,234,235,237],Uses:[31,42,139,231],Using:[20,49,93,94,268,297,302],Was:274,Will:20,With:[9,20,21,30,90,95,102,134,229,231,248,249,250,251,256,285,299,300,302],Yes:[10,19,90,134,139,252],__a:84,__asm:270,__builtin_offsetof:230,__etext:272,__n:84,__t1:84,__t2:84,__wfi:270,_access:261,_adc:286,_addr:264,_addr_:[264,265],_app:264,_build:[33,63],_cfg:[214,215],_cli:[215,216,288],_cnt:146,_config:[213,214,215,290],_file:158,_gatt_ac:261,_imghdr_siz:99,_init:[213,214,215],_itvl:103,_last:103,_len:90,_log:215,_name:232,_nrf52_adc_h_:286,_object:206,_ofb:[214,216,288],_onb:[214,216,292],_pad1:134,_pad2:134,_pad3:134,_pad:[94,104,134],_param:221,_rea:206,_reserv:213,_resource_t:287,_senseair_h_:285,_sensor:214,_set:264,_shell_init:[215,288],_stage:232,_stat:215,a600anj1:229,abbrevi:259,abc:[253,277],abil:[6,22,31,55,90,251],abl:[2,90,99,140,141,243,252,260,264,265,266,279,285,286],abort:[49,222,226,231,232,233,253,277,290],about:[1,3,10,23,29,40,57,58,59,62,64,80,81,82,91,95,99,103,105,106,146,147,151,185,206,217,229,230,241,242,246,251,259,262,263,264,265,269,273,274,280,285,286],abov:[9,10,14,19,85,90,93,95,103,106,134,158,166,185,197,221,229,230,231,232,243,253,256,259,261,264,265,268,274,277,279,284,286],absent:[134,185],abstrat:146,acc:288,accel:[288,292],accel_rev:288,acceleromet:[213,215,287,288,289,292],accept:[20,27,142,166,185,202,242,266,270,272,274,279],access:[15,20,21,27,59,61,64,70,80,81,82,87,89,94,95,99,104,140,141,142,146,158,166,173,175,179,186,187,194,202,212,213,215,216,229,232,238,246,253,256,263,266,277,285],access_:263,access_cb:[261,263,284],access_fla:166,access_flag:[166,168],accessor:90,accgyro:288,accommod:[24,90,93,102,134,185,264],accomplish:[9,10,55,179,185,261],accord:[99,134,238,239],accordingli:[24,99,105],account:[10,61,90,134],accur:272,achiev:[26,185,264,265],ack_rxd:274,acknowledg:274,acl:20,acquir:[26,94,104,185,194],acquisit:194,across:[30,31,55,61,62,140,185,187],act:[22,30,202,229],action:[9,27,62,242,251,259,263,274,286],activ:[12,16,17,21,47,71,99,105,197,202,229,242,247,249,250,259,274,295,298,299,300],actual:[2,7,34,77,90,91,99,105,134,162,169,177,185,190,229,231,233,241,251,256,264,265,266,279,280,281,285,286],ad_fil:158,adafruit:[8,286,288],adapt:[21,102,254,266,269,270,278,292],adapter_nsrst_delai:[266,270],adaptor:272,adc0:286,adc:[9,53,140],adc_0:286,adc_0_interrupt_prior:286,adc_0_oversampl:286,adc_0_resolut:286,adc_buf_read:286,adc_buf_releas:286,adc_buf_s:286,adc_buf_set:286,adc_chan_config:286,adc_config:286,adc_dev:286,adc_event_handler_set:286,adc_evq:286,adc_hw_impl:53,adc_init:286,adc_nrf52:286,adc_number_channel:286,adc_number_sampl:286,adc_read:286,adc_read_ev:286,adc_result:286,adc_result_mv:286,adc_sampl:286,adc_sns_str:286,adc_sns_typ:286,adc_sns_val:286,adc_stack:286,adc_stack_s:286,adc_stm32f4:140,adc_task:286,adc_task_handl:286,adc_task_prio:286,add:[1,2,4,6,7,11,12,27,37,39,50,55,57,58,59,61,62,80,88,90,95,102,104,106,107,136,137,146,158,187,194,214,215,222,230,232,242,243,244,246,247,248,251,253,254,256,257,260,266,267,268,275,277,278,279,288,289,290,291,293,295,296,297,298,302],added:[10,12,32,53,55,81,90,93,99,104,105,134,136,141,143,158,194,221,246,247,254,266,268,278,280,284,285,295,296,298,302],adding:[2,10,31,37,55,90,99,100,106,146,230,253,256,268,277,279,280,284,285,286],addit:[1,12,21,29,43,55,61,62,99,100,102,134,140,158,185,194,212,229,232,233,236,242,243,251,256,259,266,267,269,270,272,273,274,285,296],addition:62,addr:[27,30,91,141,206,211,257,264,265,288],addr_typ:[27,30],address:[20,21,22,25,27,29,31,32,55,66,90,91,95,134,140,141,142,157,185,194,197,206,213,215,229,247,249,254,257,261,274,278,292,299],aditihilbert:4,adjust:[20,99,246,248],admin:[4,257],adress:27,adsertis:27,adv:[21,27,30,31],adv_data:27,adv_field:[259,264],adv_param:[259,262,264,265],advanc:[59,174,185,249,250,299,300],advantag:262,advantang:259,adverb:62,adverti:[264,265],advertis:[15,20,21,24,26,31,32,66,247,258,260,262,284,286,287],advertise_128bit_uuid:287,advertise_16bit_uuid:287,advertising_interv:[27,29],advic:[100,101],advinterv:29,aes:[254,266,269,271,273,278,295,296,298],aesni:[295,296],af80:[284,286],affect:[134,174,179,180,186,212,229,244,256,275],aflag:[1,50,61],after:[4,8,11,22,26,30,41,50,55,57,58,61,80,81,84,88,100,105,106,134,135,140,144,148,152,158,179,185,197,215,229,231,236,242,243,247,251,252,254,257,259,261,262,263,266,267,278,279,288,292],again:[8,20,26,57,59,80,99,134,146,229,230,251,259,266,269,270,271,272,273,274,284,286,298],against:[22,95],agnost:158,agre:[285,286],agreement:[285,286],ah02mie2:285,ahead:106,aid:[61,215],aim:[20,141,158,258,302],ain0:286,ain1:286,air:[20,90,229,243,274,293,302],air_q:285,air_qual:[284,285,286],albeit:255,alert:258,algorithm:[21,86],align:[90,91,104,146,251],all201612161220:75,all:[1,2,3,6,7,8,9,10,12,14,15,16,17,18,20,21,22,24,26,27,28,29,30,31,35,40,41,43,49,50,51,52,53,55,61,66,72,75,90,93,94,95,99,100,102,103,105,106,134,135,136,140,146,150,156,158,165,166,169,171,172,175,177,179,181,183,185,186,187,190,206,212,213,214,215,216,217,218,219,221,226,229,230,231,232,236,238,241,242,243,244,248,252,253,256,257,258,259,260,261,262,263,264,265,268,270,272,274,275,277,279,280,281,282,284,285,286,288,290,292,295,298],alloc:[73,77,88,89,90,91,93,157,185,226,259,261],allow:[2,3,4,6,8,9,12,20,21,27,31,39,50,55,57,58,59,64,65,66,67,68,69,70,71,72,73,74,75,76,77,80,81,82,88,92,94,95,102,104,134,136,140,158,179,185,197,198,212,216,217,218,220,221,229,230,232,235,239,242,243,246,251,254,257,259,262,264,268,269,274,278,286,288,292,294],almost:[8,251],alon:239,along:[10,61,90,105,224,285],alongsid:[251,264],alphabet:[185,232],alreadi:[6,7,8,11,20,24,31,43,58,59,81,82,84,101,102,134,141,152,159,165,166,171,172,173,178,185,193,242,248,249,250,254,255,256,266,268,269,270,271,272,273,274,278,284,285,286,287,295,298,299,300],also:[1,3,5,6,7,8,11,12,21,23,24,27,34,37,40,55,57,58,59,60,61,66,80,83,90,91,95,99,102,104,105,106,134,135,136,137,140,141,146,158,179,185,197,200,202,212,213,214,215,217,219,221,229,230,231,232,242,243,244,246,251,253,254,256,259,262,263,267,268,274,275,277,278,279,280,284,285,286,288,289,290,291,292,295,296,298],alt:298,altern:[6,134,146,229,261],although:279,altogeth:[85,284],alwai:[8,61,99,106,134,162,164,166,167,174,176,185,190,253,255,261,264,265,272,277,279,280,285,302],ambigu:20,ambiti:256,amd64:[57,80],amend:[1,32,50,62,244,247,249,250,275,299,300],amg:288,among:[86,99,134,182,229],amount:[24,85,90,91,101,158,177,212,229,251,259],analog:[140,293],analyz:[12,250,300],android:[287,289,291,294],ani:[1,4,8,10,14,21,22,27,33,49,50,59,61,63,64,66,73,76,77,80,81,82,84,88,90,93,94,95,99,101,103,104,105,106,134,136,141,142,158,165,175,179,180,181,182,184,185,200,212,215,216,221,229,230,232,239,242,243,247,257,259,268,269,274,280,284,285,286,292,297,302],announc:[259,264,265],annoy:[261,281],anonym:27,anoth:[10,21,26,27,30,61,90,94,95,99,100,101,105,106,136,193,202,229,231,242,249,250,251,259,261,274,285,286,296,299,300],ans:[285,286],answer:95,anymor:[90,251],anyth:[1,8,23,34,35,37,38,39,40,41,42,43,44,45,46,47,48,49,50,51,52,53,54,57,58,59,62,229,242,248,256,264,265,267,280,285,286],apach:[1,2,6,7,10,11,12,21,32,33,37,38,39,43,44,50,51,53,55,57,58,59,61,62,63,80,81,82,99,134,136,139,140,158,190,229,230,232,242,249,250,252,253,254,256,257,258,260,264,266,267,268,269,270,271,272,273,274,277,278,279,280,285,286,287,288,289,292,294,295,296,297,298,299,300,302],apart:106,api:[1,16,17,18,19,20,21,53,55,61,95,102,105,106,140,141,168,187,191,192,193,194,196,197,198,199,200,215,216,221,230,265,270,287,291],app:[1,7,8,12,21,26,29,32,34,37,38,42,43,45,46,47,48,50,53,55,62,73,76,77,99,134,136,140,158,187,230,231,232,242,243,246,247,248,249,251,253,254,256,258,259,262,263,264,265,266,268,269,270,271,272,273,277,278,284,285,286,287,288,289,290,291,295,296,297,298,299,302],app_error:286,app_log_init:212,app_util_platform:286,appear:[27,29,102,194,251,261,263],append:[146,164,174,176,185,253,277],append_loc:[147,148],append_test:[253,277],appl:[249,250,266,292,294,299,300],appli:[12,24,134,136,179,180,185,200,212,229,232,253,274,277],applic:[1,2,4,5,6,8,9,10,11,13,14,18,20,21,23,24,25,26,28,30,34,39,42,47,50,55,57,58,59,60,61,73,76,77,78,82,83,88,90,93,99,103,105,134,136,137,138,139,140,158,179,185,191,197,215,216,217,218,219,220,221,227,230,231,232,241,247,250,253,255,258,261,262,267,276,277,284,285,291,294,296,297,300,302],applicaton:1,applict:12,approach:[31,99,232],appropri:[62,93,99,102,105,138,140,185,194,197,232,242,248,256,259,262,264,265,267,285,286,291],approv:10,apps_air_qu:285,apps_bleprph:229,apps_blinki:[55,61],apps_my_sensor_app:292,apr:[269,271,274,286],apropo:[249,250,266,292,299,300],apt:[4,6,7,56,60,79,83,257],arbitrari:[134,242,254,257,266,269,270,271,272,273,274,278,286,288,295,296,298],arbitrarili:[134,185,265],arc4:266,arch:[61,99,102,196,238,269,270,271,272,273,274,292],arch_sim:[268,292],architectur:[57,80,84,86,91,96,99,101,102,106,134,140,157,187,193,196,251],archiv:[4,7,57,59,61,172,242,243,254,256,266,268,269,270,271,272,273,274,278,285,286,288,292,295,296,298],arduino:[12,251,267,276,279,284,285,302],arduino_101:53,arduino_blinki:[12,251,266],arduino_boot:[12,266],arduino_mkr1000:[254,278],arduino_primo_nrf52:[53,269,285],arduino_zero:266,arduino_zero_debug:266,arduinowifi:[254,278],area:[90,99,134,135,146,156,180,182,183,232],area_desc:[182,183],aren:107,arg:[12,84,92,95,103,105,140,156,212,215,224,233,246,251,261,262,284,285,286,292],argc:[84,95,105,135,144,145,182,183,204,221,222,226,227,228,232,239,246,251,253,264,265,268,277,285,290,292],argument:[11,12,20,45,50,55,62,85,88,103,136,173,190,199,206,212,215,217,221,227,251,259,262,263,264,265,269,271,279,280,292],argv:[84,105,135,144,145,182,183,204,221,222,226,227,228,232,239,246,251,253,264,265,268,277,285,290,292],arm:[5,6,7,12,85,99,107,249,250,266,272,292,298,299,300],around:[30,90,134,286,287,289],arrai:[23,145,146,156,179,180,182,183,206,207,208,210,211,221,226,232,248,251,259,263],arrang:[99,229],arriv:92,articl:281,artifact:[35,39,50,55,57,58,59,279],ascii:185,asf:[1,279,285,286],ask:[10,95,135,213,251,272,279,280,285],aspect:[27,90,134,251],assembl:[1,61,99,102,269,270,271,272,273,274,292],assert:[67,90,103,136,163,176,182,183,214,230,233,246,251,261,262,263,264,265,268,284,285,286,290,292],assign:[10,19,21,23,29,37,50,53,66,95,99,105,146,185,186,232,242,254,261,266,269,270,271,272,273,274,278,286,288,295,298],associ:[22,24,88,90,103,105,134,232,233,259,262],assum:[7,12,30,43,59,60,82,83,90,99,105,134,141,197,202,232,242,243,246,248,249,250,255,256,268,274,284,285,286,287,289,291,292,299,300],asynchron:200,at45db:141,at45db_default_config:141,at45db_dev:141,at45db_erase_sector:141,at45db_init:141,at45db_read:141,at45db_sector_info:141,at45db_writ:141,at45dbxxx:141,at91samd21g18:266,at91samd:266,ate_m:213,atmel:[2,254,266,278],atop:[140,187],att:[18,21,28,261],attach:[8,12,88,99,193,249,250,256,269,274,286,292,299,300],attempt:[20,23,27,93,94,105,134,169,177,182,183,184,185,232,261,262,263,274],attempt_stat:230,attent:3,attr:[28,30,211],attr_handl:[260,261,262,284,286],attribit:206,attribut:[14,16,17,20,21,28,50,53,62,66,100,102,206,211,232,258,261],auth:[27,281],authent:[20,22,30,134,260],author:[1,20,43,61,136,277,285,286],auto:[29,141],autocomplet:55,autoconf:55,autom:31,automat:[1,10,21,24,25,42,55,61,100,203,221,230,232,236,243,253,256,258,259,266,269,270,272,273,277,279,285,286,287,302],autoselect:266,avaial:274,avail:[1,2,3,4,7,9,20,21,23,24,29,30,31,32,47,57,58,59,62,64,73,80,81,82,90,103,104,107,134,136,138,140,146,158,169,179,193,202,213,221,229,232,238,241,243,249,250,264,268,274,280,286,291,299,300],avail_queu:136,avoid:[61,94,95,103,251,287],awai:[20,99,135,261,286],await:3,awar:[259,264,265],b0_0:272,b0_1:272,b1_0:272,b1_1:272,b5729002b340:[284,286],b8d17c77a03b37603cd9f89fdcfe0ba726f8ddff6eac63011dee2e959cc316c2:247,bab:212,back:[8,58,64,69,80,81,82,106,107,134,135,136,194,219,243,263,272,273,285,291,295,296,298],backend:135,backward:[21,134,136,185,221],bad:[134,229,280],badli:95,band:[21,22,27],bang:285,bank:272,bar:[12,135,302],bare:[85,258,264,265,302],base64:[7,136,274,292],base:[1,2,4,6,7,12,20,21,24,31,34,39,55,57,58,59,61,90,107,138,140,142,174,187,194,231,251,254,257,263,266,269,270,272,273,278,285,287,288,292],baselibc:[7,48,99],baselin:139,bash:[2,12,55,59,99],bash_complet:36,bash_profil:[11,58,60,81,83],bashrc:55,basi:[9,19,22,105,280,285,286],basic:[1,14,21,29,30,31,61,90,93,99,105,107,140,158,189,191,193,200,229,243,247,254,256,257,274,279,281,283,284,294,296,297],batch:99,batteri:[9,24,31,102,264],baud:[66,136,257,285],baudrat:[141,197],bbno055_cli:288,bc_acc_bw:[215,290],bc_acc_rang:[215,290],bc_mask:[215,290],bc_opr_mod:[215,290],bc_placement:215,bc_pwr_mode:[215,290],bc_unit:[215,290],bc_use_ext_xt:290,bcfg:290,bd_addr:20,be9699809a049:71,beacon:[14,255,256,267],bearer:[21,32],becaus:[8,10,12,20,22,26,30,50,88,134,175,185,186,194,197,213,215,218,222,229,231,251,253,277,279,281,285,287,288,289,292],becom:[22,31,134,259,262],been:[4,10,20,26,36,43,55,58,59,61,77,81,82,84,89,90,91,97,98,105,134,135,144,146,158,159,171,179,185,197,200,229,232,252,254,257,262,266,269,274,278,284,285],befor:[2,4,7,8,12,20,41,50,57,61,80,84,85,88,89,94,95,96,99,103,105,106,107,134,135,136,146,152,179,180,184,197,199,200,206,217,218,221,223,229,230,232,238,239,243,246,251,253,254,256,257,258,259,261,264,265,267,268,270,274,277,278,286,291,294,297],begin:[26,146,154,253,257,260,262,264,265,277,279],beginn:302,behav:[20,30,95,253,264,265,277],behavior:[59,95,102,167,168,179,250,251,253,254,261,263,277,278,300],behaviour:93,behind:[93,106],being:[20,91,95,103,105,134,135,141,158,185,195,196,204,205,229,233,251,253,260,262,277,285,302],bell:104,belong:[14,134,185,263],below:[1,2,4,6,12,18,20,22,23,24,30,43,62,90,95,99,100,104,105,134,136,138,141,159,166,169,185,186,188,199,215,229,242,244,251,253,256,261,263,266,269,270,271,272,273,274,275,277,279,280,281,284,286,287,288,290,294,302],benefit:[10,95,185,232,241,246],best:[99,166,206,280],beta:[140,286],better:[134,230],between:[7,12,21,26,27,31,37,46,55,104,106,136,185,193,194,204,206,216,229,231,232,243,246,257,269,274,280,286,288,292],beyond:185,bhd:66,big:[23,61,90,274,280],bigger:229,bin:[2,4,7,11,12,34,35,37,38,43,46,48,50,55,57,58,59,60,61,80,81,82,83,99,174,175,229,232,242,243,247,248,249,250,253,254,256,257,260,266,268,269,270,271,272,273,274,277,278,285,286,288,292,295,296,298,299,300],bin_basenam:61,binari:[4,7,11,34,37,39,55,58,60,61,79,81,83,107,138,194,268,285],binutil:4,bit:[7,14,23,25,27,29,57,58,59,66,81,82,84,87,90,91,105,106,107,134,185,194,195,213,215,217,218,229,230,249,250,251,254,256,261,262,263,264,265,278,280,285,286,287,292,299,300],bitbang:195,bits0x00:27,bl_rev:288,bla:212,ble:[14,18,19,23,26,30,31,61,64,65,66,67,68,69,70,71,72,73,74,75,76,77,80,81,82,90,134,138,139,229,232,243,247,255,257,259,261,262,263,267,283,284,285,289,291,294,302],ble_:261,ble_addr_t:[264,265],ble_addr_type_publ:262,ble_app:[256,264,265],ble_app_advertis:[264,265],ble_app_on_sync:[264,265],ble_app_set_addr:[264,265],ble_att:[76,243,261],ble_att_err_attr_not_found:20,ble_att_err_attr_not_long:20,ble_att_err_insufficient_authen:20,ble_att_err_insufficient_author:20,ble_att_err_insufficient_enc:20,ble_att_err_insufficient_key_sz:20,ble_att_err_insufficient_r:[20,284,286],ble_att_err_invalid_attr_value_len:[20,261],ble_att_err_invalid_handl:20,ble_att_err_invalid_offset:20,ble_att_err_invalid_pdu:20,ble_att_err_prepare_queue_ful:20,ble_att_err_read_not_permit:20,ble_att_err_req_not_support:20,ble_att_err_unlik:[20,284,286],ble_att_err_unsupported_group:20,ble_att_err_write_not_permit:20,ble_att_svr_entry_pool:73,ble_att_svr_prep_entry_pool:73,ble_eddystone_set_adv_data_uid:264,ble_eddystone_set_adv_data_url:264,ble_eddystone_url_scheme_http:264,ble_eddystone_url_suffix_org:264,ble_err_acl_conn_exist:20,ble_err_auth_fail:20,ble_err_chan_class:20,ble_err_cmd_disallow:20,ble_err_coarse_clk_adj:20,ble_err_conn_accept_tmo:20,ble_err_conn_establish:20,ble_err_conn_limit:20,ble_err_conn_parm:20,ble_err_conn_rej_bd_addr:20,ble_err_conn_rej_channel:20,ble_err_conn_rej_resourc:20,ble_err_conn_rej_secur:20,ble_err_conn_spvn_tmo:20,ble_err_conn_term_loc:20,ble_err_conn_term_m:20,ble_err_ctlr_busi:20,ble_err_diff_trans_col:20,ble_err_dir_adv_tmo:20,ble_err_encryption_mod:20,ble_err_host_busy_pair:20,ble_err_hw_fail:20,ble_err_inq_rsp_too_big:20,ble_err_instant_pass:20,ble_err_insufficient_sec:20,ble_err_inv_hci_cmd_parm:20,ble_err_inv_lmp_ll_parm:20,ble_err_link_key_chang:20,ble_err_lmp_collis:20,ble_err_lmp_ll_rsp_tmo:20,ble_err_lmp_pdu:20,ble_err_mac_conn_fail:20,ble_err_mem_capac:20,ble_err_no_pair:20,ble_err_no_role_chang:20,ble_err_page_tmo:20,ble_err_parm_out_of_rang:20,ble_err_pending_role_sw:20,ble_err_pinkey_miss:20,ble_err_qos_parm:20,ble_err_qos_reject:20,ble_err_rd_conn_term_pwroff:20,ble_err_rd_conn_term_resrc:20,ble_err_rem_user_conn_term:20,ble_err_repeated_attempt:20,ble_err_reserved_slot:20,ble_err_role_sw_fail:20,ble_err_sco_air_mod:20,ble_err_sco_itvl:20,ble_err_sco_offset:20,ble_err_sec_simple_pair:20,ble_err_synch_conn_limit:20,ble_err_unit_key_pair:20,ble_err_unk_conn_id:20,ble_err_unk_lmp:20,ble_err_unknown_hci_cmd:20,ble_err_unspecifi:20,ble_err_unsupp_lmp_ll_parm:20,ble_err_unsupp_qo:20,ble_err_unsupp_rem_featur:20,ble_err_unsupport:20,ble_ga:263,ble_gap:76,ble_gap_adv_param:[264,265],ble_gap_adv_set_field:259,ble_gap_adv_start:[259,262,264,265],ble_gap_chr_uuid16_appear:[261,263],ble_gap_chr_uuid16_device_nam:[261,263],ble_gap_chr_uuid16_periph_pref_conn_param:261,ble_gap_chr_uuid16_periph_priv_flag:261,ble_gap_chr_uuid16_reconnect_addr:261,ble_gap_conn_desc:262,ble_gap_conn_find:262,ble_gap_conn_fn:259,ble_gap_conn_mode_und:[259,262],ble_gap_disc_mode_gen:[259,262],ble_gap_ev:262,ble_gap_event_conn_upd:262,ble_gap_event_connect:262,ble_gap_event_disconnect:262,ble_gap_event_enc_chang:262,ble_gap_event_fn:[264,265],ble_gap_event_subscrib:262,ble_gap_svc_uuid16:[261,263],ble_gap_upd:73,ble_gatt:76,ble_gatt_access_ctxt:[261,284,286],ble_gatt_access_op_read_chr:[261,284,286],ble_gatt_access_op_write_chr:[261,284,286],ble_gatt_chr_def:[261,263,284],ble_gatt_chr_f_notifi:284,ble_gatt_chr_f_read:[261,263,284],ble_gatt_chr_f_read_enc:284,ble_gatt_chr_f_writ:284,ble_gatt_chr_f_write_enc:284,ble_gatt_register_fn:263,ble_gatt_svc_def:[261,263,284],ble_gatt_svc_type_primari:[261,263,284],ble_gattc:76,ble_gattc_proc_pool:73,ble_gatts_chr_upd:[284,286],ble_gatts_clt_cfg_pool:73,ble_gatts_find_chr:[284,286],ble_gatts_register_svc:263,ble_h:[14,15,16,17,19,20,23,26,76,264,265,286],ble_hci_ram_evt_hi_pool:73,ble_hci_ram_evt_lo_pool:73,ble_hci_uart_baud:257,ble_hs_:263,ble_hs_adv_field:[259,264],ble_hs_att_err:20,ble_hs_cfg:[26,264,265],ble_hs_conn_pool:73,ble_hs_eagain:20,ble_hs_ealreadi:20,ble_hs_eapp:20,ble_hs_eauthen:20,ble_hs_eauthor:20,ble_hs_ebaddata:20,ble_hs_ebusi:20,ble_hs_econtrol:20,ble_hs_edon:20,ble_hs_eencrypt:20,ble_hs_eencrypt_key_sz:20,ble_hs_einv:20,ble_hs_emsgs:20,ble_hs_eno:20,ble_hs_enoaddr:20,ble_hs_enomem:20,ble_hs_enomem_evt:20,ble_hs_enotconn:20,ble_hs_enotsup:20,ble_hs_enotsync:20,ble_hs_eo:20,ble_hs_ereject:20,ble_hs_erol:20,ble_hs_err_sm_peer_bas:20,ble_hs_err_sm_us_bas:20,ble_hs_estore_cap:20,ble_hs_estore_fail:20,ble_hs_etimeout:20,ble_hs_etimeout_hci:20,ble_hs_eunknown:20,ble_hs_ev_tx_notif:88,ble_hs_event_tx_notifi:88,ble_hs_forev:[262,264,265],ble_hs_hci_err:20,ble_hs_hci_ev_pool:73,ble_hs_id:23,ble_hs_id_gen_rnd:[23,264,265],ble_hs_id_set_rnd:[19,23,264,265],ble_hs_l2c_err:20,ble_hs_reset_fn:26,ble_hs_sm_peer_err:20,ble_hs_sm_us_err:20,ble_hs_sync_fn:26,ble_ibeacon_set_adv_data:265,ble_l2cap:76,ble_l2cap_chan_pool:73,ble_l2cap_sig_err_cmd_not_understood:20,ble_l2cap_sig_err_invalid_cid:20,ble_l2cap_sig_err_mtu_exceed:20,ble_l2cap_sig_proc_pool:73,ble_ll:[76,77,285],ble_ll_cfg_feat_le_encrypt:229,ble_ll_conn:76,ble_ll_prio:232,ble_lp_clock:24,ble_max_connect:[287,289],ble_mesh_dev_uuid:32,ble_mesh_pb_gatt:32,ble_own:[264,265],ble_own_addr_random:[264,265],ble_phi:76,ble_prph:285,ble_public_dev_addr:23,ble_rigado:47,ble_role_broadcast:289,ble_role_peripher:289,ble_sm_err_alreadi:20,ble_sm_err_authreq:20,ble_sm_err_cmd_not_supp:20,ble_sm_err_confirm_mismatch:20,ble_sm_err_cross_tran:20,ble_sm_err_dhkei:20,ble_sm_err_enc_key_sz:20,ble_sm_err_inv:20,ble_sm_err_numcmp:20,ble_sm_err_oob:20,ble_sm_err_pair_not_supp:20,ble_sm_err_passkei:20,ble_sm_err_rep:20,ble_sm_err_unspecifi:20,ble_sm_legaci:229,ble_tgt:[256,264,265],ble_uu:263,ble_uuid128_init:[284,286],ble_uuid128_t:[284,286],ble_uuid16:[261,263],ble_uuid16_declar:[284,286],ble_uuid:286,ble_uuid_128_to_16:261,ble_uuid_u16:[284,286],ble_xtal_settle_tim:24,bleadc:286,blecent:[7,61],blehci:[7,61],blehciproj:257,blehostd:66,blemesh:[21,32],blenano:53,bleprph:[7,21,61,66,229,247,250,258,259,260,261,262,263,284,285,286,287,300],bleprph_advertis:[259,262],bleprph_appear:261,bleprph_device_nam:[259,261],bleprph_log:[259,262,284,286],bleprph_oic:[7,61,291],bleprph_oic_sensor:287,bleprph_on_connect:259,bleprph_pref_conn_param:261,bleprph_print_conn_desc:262,bleprph_privacy_flag:261,bleprph_reconnect_addr:261,blesplit:[7,61],bletest:[7,61],bletini:[7,21,37,38,45,46,50,61,71,243,257,260],bletiny_chr_pool:73,bletiny_dsc_pool:73,bletiny_svc_pool:73,bletoh:90,bleuart:[7,61],blink:[1,7,61,99,105,193,246,248,251,266,267,269,270,271,272,273,285,286,302],blink_nord:[250,300],blink_nrf:285,blink_primo:285,blink_rigado:47,blinki:[1,12,34,43,44,48,55,61,99,249,250,251,254,256,257,274,278,285,286,294,295,296,298,299,300,302],blinky_callout:268,blinky_primo:285,blinky_sim:61,blinky_task_handl:193,blksize:91,blksz:[73,296],blob:[20,190],block:[20,29,73,84,88,90,91,104,140,146,149,179,180,181,182,183,197,200,246,285,296],block_siz:91,blue:273,bluetooth:[1,9,20,22,23,24,27,29,32,90,229,247,258,259,264,265,267,285,286,302],bmd300eval:[48,53,271,286],bmd:[271,286],bno055:[214,215,287,289,290],bno055_0:[214,288,290],bno055_acc_cfg_bw_125hz:290,bno055_acc_cfg_rng_16g:290,bno055_acc_unit_ms2:290,bno055_angrate_unit_dp:290,bno055_cfg:[215,290],bno055_cli:[288,289],bno055_config:[215,290],bno055_default_cfg:215,bno055_do_format_android:290,bno055_err:215,bno055_euler_unit_deg:290,bno055_get_chip_id:215,bno055_id:215,bno055_info:215,bno055_init:[214,215],bno055_ofb:[214,287,288,289],bno055_opr_mode_ndof:290,bno055_pwr_mode_norm:290,bno055_sensor_get_config:215,bno055_sensor_read:215,bno055_shel:288,bno055_shell_init:288,bno055_stat_sect:215,bno055_temp_unit_degc:290,board:[1,2,4,5,7,8,10,12,23,24,30,39,42,47,53,55,57,58,59,61,95,99,140,187,189,194,215,216,220,229,231,232,242,243,246,247,248,249,250,251,257,260,264,265,267,268,284,285,290,291,292,294,297,299,300,302],bodi:[134,290],bold:[242,252],bond:[22,27,29,30,260],bondabl:27,bone:[85,258,264,265,302],bookkeep:146,bool:206,boot:[7,10,43,61,99,106,107,136,202,242,243,247,254,257,266,269,270,271,272,273,274,278,285,286,288,292,295,296,298],boot_boot_serial_test:7,boot_bootutil:229,boot_build_statu:134,boot_build_status_on:134,boot_clear_statu:134,boot_copy_area:134,boot_copy_imag:134,boot_erase_area:134,boot_fill_slot:134,boot_find_image_area_idx:134,boot_find_image_part:134,boot_find_image_slot:134,boot_go:134,boot_img_mag:134,boot_init_flash:134,boot_load:99,boot_mag:134,boot_move_area:134,boot_nrf:285,boot_olimex:272,boot_primo:285,boot_read_image_head:134,boot_read_statu:134,boot_select_image_slot:134,boot_seri:[7,136],boot_serial_setup:7,boot_slot_addr:134,boot_slot_to_area_idx:134,boot_swap_area:134,boot_test:7,boot_vect_delete_main:134,boot_vect_delete_test:134,boot_vect_read_main:134,boot_vect_read_on:134,boot_vect_read_test:134,boot_write_statu:134,bootabl:[229,247,295,298],bootload:[1,12,43,47,99,102,107,136,202,242,247,251,267,268,285,286,287,289,297],bootutil:[7,107,134,136,254,266,269,270,271,272,273,274,278,288,295,296,298],bootutil_misc:[7,266,269,270,271,273,288,295,296,298],both:[6,9,11,14,20,22,27,29,39,55,57,58,59,62,90,94,99,104,134,135,137,140,179,185,194,197,206,212,229,231,232,241,253,254,266,268,274,277,278,281,286],bottl:[58,81],bottom:[12,99,103,260],bound:[99,158],boundari:[90,91,99],box:[12,250,300],branch:[1,4,7,10,11,55,56,57,59,60,79,80,82,83,134,252,254,266,278,279,280],branchnam:10,brand:273,bread:286,breadboard:286,breakdown:229,breakout:8,breakpoint:[266,270],breviti:[229,242,296],brew:[3,4,7,11,36,55,58,60,81,83],brick:134,bridg:185,brief:[19,188,193,264,265,274],briefli:99,bring:[12,99,187,288,291,294],broad:302,broadca:[264,265],broadcast:[14,27,31,259,264,265],brows:[260,269,279],browser:252,bsd:107,bsp:[1,7,24,32,34,37,38,42,43,45,47,50,55,61,62,95,96,135,140,179,180,182,183,187,189,192,193,213,214,215,216,218,229,232,242,246,249,250,254,256,257,260,266,268,269,270,271,272,273,274,278,285,286,287,288,289,290,292,295,296,298,299,300,302],bsp_arduino_zero:266,bsp_arduino_zero_pro:[254,266,278],bsp_flash_dev:180,bsp_timer:199,bsppackag:99,bss:[48,99,229],bssnz_t:[284,285,286],btattach:257,btshell:29,buad:66,buf:[135,141,159,160,161,162,166,167,169,170,174,177,206],buffer:[10,20,90,91,95,102,103,136,140,162,169,175,177,185,194,206,212,231,265,286],buffer_len:286,buffer_size_down:[249,299],bug:[4,7,11,166,167,249,250,266,270,292,299,300],bui:286,build:[1,2,3,4,5,6,11,31,32,35,37,38,39,40,41,42,43,44,45,46,47,48,49,50,51,52,53,54,57,58,59,62,80,82,95,99,100,102,134,140,187,194,205,212,216,229,230,231,232,238,246,247,253,258,259,260,267,277,284,285,294,297,302],build_arduino_blinki:12,build_arduino_boot:12,build_numb:204,build_profil:[1,32,37,38,43,50,53,61,99,229,242,254,256,257,260,266,269,270,271,272,273,274,278,285,286,287,288,289,292,295,296,298],buildabl:7,builder:252,built:[1,4,7,8,9,21,33,34,38,39,42,43,55,57,58,59,60,61,63,81,82,83,93,134,197,212,229,238,242,243,252,253,254,256,257,260,264,265,266,267,268,269,270,271,272,273,274,277,278,284,285,286,287,288,292,295,296,298],bunch:285,bundl:[55,107,158],burn:[264,265],bus:[2,194],buse:[140,187],busi:[20,91,94,251,285],button1_pin:246,button:[2,4,10,12,104,246,266,269],bytes_read:[159,166,169,174,177],bytyp:218,c_ev:85,c_evq:85,c_next:85,c_tick:85,cabl:[243,246,247,251,254,257,266,267,269,270,271,272,274,278,286,292,294,295,297,298],cach:[58,81,140,179,181,187],cache_large_file_test:[253,277],calcul:[20,29,48,106,134,146],calendar:9,call:[6,7,9,11,19,21,23,26,36,61,84,85,86,88,89,90,91,92,93,94,95,96,97,98,99,103,104,105,106,107,134,135,136,137,138,140,141,144,146,147,148,149,151,152,156,164,167,171,174,177,178,181,182,184,185,186,190,194,196,197,199,201,203,206,212,213,214,215,217,218,219,221,223,224,227,230,232,234,235,236,237,238,239,240,243,246,251,253,255,256,259,260,261,262,263,264,265,266,268,274,277,279,285,286,287,288,292,297],callback:[20,26,84,88,136,146,151,156,197,199,213,214,215,217,219,232,246,259,261,263,264,265,268,285,292],caller:[136,146,205,206,222,226],callout:[88,95,103,218,268,292],callout_l:246,callout_reset:135,came:257,can:[1,2,3,4,5,6,7,8,9,11,12,19,20,21,22,23,24,27,30,31,33,34,35,42,45,50,55,57,58,59,60,61,62,63,64,66,72,76,80,81,82,83,84,85,86,88,90,91,93,94,95,99,100,102,103,104,105,107,134,135,136,137,140,141,142,143,146,147,149,151,152,156,157,158,167,171,172,175,177,179,180,182,185,186,187,193,195,196,197,199,201,202,206,212,213,214,215,216,217,218,221,222,226,227,228,229,230,231,232,234,235,237,238,241,242,243,244,246,247,248,249,250,251,252,253,254,256,257,259,260,261,262,263,264,265,266,267,268,269,270,271,272,273,274,275,277,278,279,280,284,285,286,287,288,289,290,292,294,295,296,298,299,300,302],cancel:[20,27,85],candid:279,cannot:[4,19,20,71,84,85,88,90,91,92,93,94,95,103,104,134,135,157,175,185,232,243,254,266,278,279,280,281],capabl:[20,22,27,29,101,136,140,212,229,249,251,268,299],capac:20,captian:81,captur:185,carbon:284,card:[142,157],care:[90,95,105,169,177,264,265,279,280,284],carri:90,cascad:[1,61],cast:261,cat:[80,285,286],catastroph:26,categor:99,categori:[10,102],caus:[95,104,159,166,167,172,175,185,194,198,231,233,247,249,251,286,299],caveat:134,cb_arg:[156,199,259,263,264,265],cb_func:199,cbmem:[7,212,233],cbmem_buf:212,cbmem_entry_hdr:233,cbmem_init:212,cbmem_read:233,cbmem_test_case_1_walk:233,cbor:[138,139],cborattr:7,cccd:27,ccm:22,cdc:269,cell:22,cellar:[4,6,11,36,58,60,81,83],central:[20,30,258,259,260,262],certain:[1,21,90,91,95,99,140,257,280],certainli:286,cess_op_:261,cf_arg:85,cf_c:85,cf_func:85,cfg:[70,177,178,214,215,270],cflag:[1,50,61,99],cgi:107,ch_commit:135,ch_export:135,ch_get:135,ch_name:135,ch_set:135,chain:[90,91,93,103,104,206],challeng:[244,275],chanc:[95,105],chang:[1,4,6,7,10,11,19,20,21,22,24,28,30,46,49,50,52,57,61,62,80,93,99,100,134,185,213,214,221,229,231,232,242,243,246,248,249,250,251,252,257,260,262,264,265,266,270,284,285,286,287,288,289,292,294,299,300],channel:[20,21,29,140,286],channel_map:27,chapter:[2,21,102,138],charact:[136,145,162,165,179,185,200,204,205,206,207,208,209,210,221,226,232,249,254,263,278,292,299],character:24,characteri:[261,263],characterist:[9,16,17,21,27,28,134,260,263,284,286],check:[4,6,8,11,20,22,55,56,79,91,135,185,201,206,215,229,231,232,242,247,253,256,257,258,269,272,274,277,280,285,288,290,297],checkbox:59,checkin:[77,103],checkout:[10,80,82,267],checksum:[146,148],child:[160,161,162,167,170,185],children:185,chip:[4,102,140,141,187,193,197,198,213,215,254,266,267,269,270,273,278,279,285,288],chip_id:288,chipset:[140,187,254,266,278],choic:[2,10,179,257,288],choos:[6,7,10,93,105,107,229,230,243,251,256,259,268,269,271,284,286],chose:230,chosen:[93,99,134,157,185,286],chr:[261,284,286],chr_access:261,chr_val_handl:[284,286],chunk:10,ci40:53,cid:260,circuit:194,circular:[212,231,232],circularli:280,cks:91,clang:6,clarif:10,clarifi:140,clariti:142,classif:20,clean:[1,11,33,39,50,57,58,59,63,81,165,183,251,274],cleanli:232,clear:[72,134,185],clearli:[8,20],cli:136,click:[2,4,10,12,252,260,264,265,266,269,270,272,298],client:[12,17,18,20,21,27,31,158,186,216,264,284],clk:197,clobber:172,clock:[20,25,87,196,266,270,288],clock_freq:84,clone:[10,11,45,50,55,58,81],close:[2,59,140,158,159,160,161,162,163,166,167,169,170,174,175,176,177,178,200,214,266,269,270,272,273,290],cmake:1,cmd:[55,61,99,285,288],cmd_len:285,cmd_queue:136,cmd_read_co2:285,cmp:285,cmsi:[2,7,48,99,266,269,270,271,272,273,292],cmsis_nvic:[99,269,270,271,272,273,292],cn4:242,cnt:[73,136,182,183,296],co2:[284,285],co2_evq:284,co2_read_ev:284,co2_sns_str:284,co2_sns_typ:284,co2_sns_val:284,co2_stack:284,co2_stack_s:284,co2_task:284,co2_task_handl:284,co2_task_prio:284,coap:[139,216,219,287,291],coars:20,coc:27,code:[1,5,7,9,11,13,18,21,24,26,27,29,55,86,90,91,92,93,95,101,102,106,107,134,136,138,140,142,145,158,159,160,161,162,163,165,166,167,169,170,172,174,175,176,177,178,182,183,184,185,186,187,193,202,212,214,215,216,229,232,233,234,235,237,238,239,243,246,251,254,258,259,261,262,263,266,267,268,274,276,278,279,285,286,287,290,291,292,294,296,297,302],codebas:[254,266,278],coded_interval_max:27,coded_interval_min:27,coded_lat:27,coded_max_conn_event_len:27,coded_min_conn_event_len:27,coded_scan_interv:27,coded_scan_window:27,coded_timeout:27,codepag:157,coding_standard:7,coexist:134,collect:[1,7,43,55,61,90,91,138,146,186,206,229,242,279],collis:20,colon:66,color:248,column:19,com11:8,com1:66,com3:[8,254,268,278,288,295,298],com6:8,com:[8,10,11,12,33,55,57,58,59,63,80,81,82,107,190,242,254,257,268,278,279,281,288,295,296,298],combin:[1,20,22,26,43,61,95,99,194,256,264,265,279,280],combo:229,come:[3,21,30,55,61,99,107,136,140,212,254,266,272,273,278,285,286,298],comm:[242,267],comma:[51,66],comman:227,command:[1,2,4,7,8,10,11,20,30,34,35,36,37,38,40,41,42,44,45,46,47,48,49,51,52,53,54,57,58,59,60,61,67,68,70,71,72,75,76,78,80,81,82,83,99,102,134,137,139,142,144,194,202,203,212,216,222,226,227,228,229,230,231,232,238,242,244,245,247,248,249,250,251,253,254,256,264,265,266,268,269,270,271,272,273,274,275,277,278,279,281,282,286,287,288,289,290,292,295,298,299,300],comment:[3,10,99,241,302],commerci:285,commit:[10,11],common:[55,61,88,90,92,102,104,140,141,187,193,215,216,229,263,270],commonli:[104,197,264],commun:[9,21,26,27,31,66,78,136,138,142,194,197,213,214,215,242,246,247,248,251,254,257,259,262,267,274,278,279,285,286,288,292,295,296,297,298,302],compani:29,compar:[10,20,166,251,269,270,271,274,282,286],comparison:[20,22,106],compat:[4,10,21,55,134,136,141,221,222,229,249,254,266,274,278,288,290,292,299],compens:106,compil:[1,4,5,6,7,8,11,20,34,47,53,55,58,61,81,90,99,102,107,140,221,230,232,238,241,242,243,246,254,256,266,269,270,271,272,273,274,278,285,286,287,288,292,295,296,298],complaint:21,complementari:31,complet:[9,12,20,22,27,29,30,33,55,59,63,88,99,101,102,105,134,136,146,160,161,162,167,170,185,187,197,212,229,236,240,241,246,251,257,259,264,265,270,279,286,287,290,291,292,295,296,298],completion_cb:136,complex:[9,31,95,99,140,187,251,255],compli:21,complianc:[285,286],compliant:21,complic:[55,95,229],compon:[1,7,12,18,39,48,55,57,58,59,61,86,99,102,135,140,187,194,197,229,230,243,246,247,254,257,264,265,267,278,285,294,297],compos:[39,57,58,59,241],composit:206,comprehens:241,compress:[55,81,179,264],compris:[7,134,179,180],comput:[3,4,6,8,12,31,56,58,59,79,81,136,148,157,247,251,256,257,266,267,269,270,271,272,273,287,289,294,295,297,298],concept:[12,22,90,95,166,221,232,247,251,254,255,256,258,266,267,278,294,297],concern:[3,90,185],concis:138,conclud:[264,265,286],concurr:[1,34,35,37,38,39,40,41,42,43,44,45,46,47,48,49,50,51,52,53,54,57,58,59,62,85,89,258,259],condit:[4,20,134,185,194,214,221,231,233,253,277,285,286],condition:[55,214,231,232,288],conduct:[134,138],conf:274,conf_export_tgt:135,conf_fcb_dst:135,conf_fcb_src:135,conf_file_dst:135,conf_file_src:135,conf_get_valu:135,conf_handl:135,conf_init:239,conf_int8:135,conf_load:135,conf_regist:[135,233],conf_sav:135,conf_save_on:135,conf_set_valu:135,conf_str_from_valu:135,conf_value_set:135,confidenti:22,config:[1,7,32,50,61,62,64,78,80,81,82,137,141,157,159,163,166,169,176,231,232,239,243,256,285,286,288],config_:214,config__sensor:214,config_bno055_sensor:[214,290],config_cli:135,config_fcb:[135,231],config_fcb_flash_area:[231,232],config_lis2dh12_sensor:214,config_newtmgr:[50,243],config_nff:[135,158,231],config_pkg_init:232,config_test_al:239,config_test_handl:233,config_test_insert:[233,234],configur:[6,7,9,19,20,25,26,31,32,50,55,57,58,59,61,62,87,95,99,100,102,134,136,138,140,158,179,181,185,187,189,197,199,216,217,219,229,244,246,249,250,251,256,259,263,266,269,272,273,274,275,281,286,288,291,292,294,296,299,300],configuraton:157,confirm:[8,20,27,71,134,229,247,274,295,298],confirmbe9699809a049:71,conflict:[61,231,280],confluenc:10,confus:[279,286],congratul:[7,242,260,284,285,286],conjunct:[31,217],conn:[27,28,30,64,65,67,68,69,70,71,72,73,74,75,76,77,78,80,81,82,247,262,264,265,295,296,298],conn_handl:[20,260,261,262,284,286],conn_interval_max:29,conn_interval_min:29,conn_itvl:[30,260],conn_lat:[30,260],conn_mod:262,conn_profil:[65,66,67,68,69,70,71,72,73,74,75,76,77],conn_upd:262,connect:[4,7,8,9,10,12,15,20,21,22,24,26,28,29,31,38,42,43,55,64,65,66,67,68,69,70,71,72,73,74,75,76,77,78,80,81,82,102,136,138,139,140,187,194,197,198,229,242,246,258,259,260,261,262,264,265,267,284,285,294,297],connect_don:[254,278],connectable_mod:259,connection_profil:71,connectionless:27,connector:[4,243,257,269,272,274,298],connextra:10,connintervalmax:29,connintervalmin:29,connstr:[66,247,295,296,298],conntyp:10,consecut:103,consequ:[20,134,229],conserv:[9,90,102],consid:[21,62,90,95,104,148,194,233,263,279],consider:233,consist:[1,21,31,61,104,105,134,135,138,140,168,185,197,229,231,232,238,263],consol:[1,7,8,12,26,55,61,102,107,135,143,160,161,162,167,170,177,200,212,225,232,246,253,256,257,260,264,265,267,277,285,286,296],console_append_char_cb:136,console_blocking_mod:136,console_compat:136,console_echo:136,console_handle_char:136,console_init:136,console_input:136,console_is_init:136,console_is_midlin:136,console_max_input_len:136,console_non_blocking_mod:136,console_out:136,console_pkg_init:232,console_printf:[20,26,136,159,160,161,162,166,167,169,170,174,177,233,284,285,286,292],console_prompt:285,console_read:136,console_rtt:[136,249,292,299],console_rx_cb:136,console_set_completion_cb:136,console_set_queu:136,console_tick:[136,285],console_uart:[136,249,292,299],console_uart_baud:136,console_uart_dev:136,console_uart_flow_control:136,console_uart_tx_buf_s:136,console_writ:[136,233],consolid:185,consortium:138,constantli:[254,259,278,286,302],constitu:[43,185],constrain:[9,55,139,244,275],constraint:266,construct:[11,92,104],consult:[158,187],consum:[88,104],consumpt:22,contact:[100,101,242],contain:[1,3,7,11,29,31,34,50,55,61,85,90,91,99,101,102,106,134,136,138,140,143,146,159,162,163,166,169,172,173,174,176,182,185,189,193,200,202,204,205,206,217,225,229,230,232,233,236,238,241,253,256,257,259,261,263,264,265,274,277,279,280,288,302],content:[12,49,61,80,99,134,146,147,148,160,161,162,167,170,177,185,199,206,229,239,242,251,253,259,263,264,265,272,274,277,280,281,288,290],context:[55,77,84,86,88,95,97,105,136,140,145,221,223,232,243,246,262,268],contigu:[90,134,146,185],continu:[6,99,104,135,185,221,229,243,246,248,249,251,252,254,257,266,267,272,278,286,289,290,291,292,294,296,297,299],contrast:232,contribut:[13,22,57,58,59,80,81,82,253,255,277,294],contributor:[187,285,286],control:[8,9,18,19,20,21,22,23,25,26,29,31,55,66,102,136,140,146,166,179,187,190,193,197,212,215,221,232,256,270,272,279,280,285,286,291],contruct:260,convei:90,conveni:[12,20,90,135,177,185,205,233],convent:[253,274,277,288,292],convers:[107,140,261],convert:[1,8,20,71,84,85,90,106,135,140,180,182,183,185,206,232,261,263,285,286],coordin:[287,289],copi:[1,4,45,49,50,62,80,82,90,100,101,134,146,185,206,214,229,230,247,249,250,259,262,266,285,286,290,292,299,300],copy_don:134,copyright:[4,249,250,266,272,285,286,292,299,300],core:[1,6,7,12,21,29,32,37,38,43,48,50,51,53,55,61,62,71,85,88,89,90,91,92,93,94,99,101,103,104,135,138,140,158,187,190,229,230,242,249,250,251,253,254,256,257,258,259,260,266,267,268,269,270,271,272,273,274,277,278,279,280,285,286,287,288,289,292,294,295,296,297,298,299,300,302],core_cminstr:270,core_o:136,core_path:61,coreconvert:71,coredownload:71,coredump:[7,189],coredump_flash_area:232,coreeras:71,corelist:71,corner:272,corp:[2,266],correct:[1,2,4,41,91,99,134,179,229,232,251,253,257,270,271,272,274,277,286,288],correctli:[2,90,248,253,257,266,270,277,286,287],correspo:263,correspond:[12,20,84,90,99,134,168,181,185,186,212,213,259,261,264,265,280,286],corrupt:[173,185],corrupt_block_test:[253,277],corrupt_scratch_test:[253,277],cortex:[4,107,196,254,269,271,274,278,286,292],cortex_m0:[61,196],cortex_m4:[61,99,269,270,271,272,273,274,292],cortex_m:266,cost:9,could:[20,90,104,185,204,261,285],couldn:[233,259,285],count:[55,81,104,134,135,185],counter:[86,92,230,274],countri:21,coupl:[1,272,285,286],cours:284,cover:[8,61,140,185,232,241,251,263],cpptool:12,cpu:[86,99,101,140,187,196,251,266,270],cputim:[24,84,87,288,292],cputime_geq:[84,87],cputime_gt:[84,87],cputime_leq:[84,87],cputime_lt:[84,87],crank:286,crash:[64,78,80,81,82,103,134,137,243],crash_test:[7,137,243],crash_test_newtmgr:243,crc16:185,crc:[7,136,142,285],creat:[1,2,3,4,5,6,8,10,11,12,22,27,32,34,39,41,43,44,45,46,47,50,55,57,58,59,61,62,66,71,80,81,82,88,91,93,95,101,103,104,105,107,136,140,149,163,165,166,167,172,175,176,178,179,182,185,212,213,215,216,218,219,223,229,230,231,232,238,240,246,248,251,258,263,267,268,279,281,284,290,291,294,297,302],create_arduino_blinki:12,create_mbuf_pool:90,create_path:165,creation:[47,140,242,274,286],creator:[213,214,215,216,218,287,288,290,292],credenti:281,criteria:20,critic:3,cross:[5,6,7,9,102],crt0:48,crti:48,crtn:48,crw:8,crypto:[7,254,266,269,271,273,278,295,296,298],crypto_mbedtl:229,cryptograph:[22,134],cryptographi:22,crystal:25,csrk:27,css:252,cssv6:29,csw:[77,285,295,298],ctassert:84,ctlr_name:66,ctlr_path:66,ctrl:[12,249,256,285,288,299],ctxt:[261,262,284,286],cur_ind:262,cur_notifi:262,curi:[260,262],curiou:[3,252],curl:[11,58],curn:[260,262],curr:278,currantlab:[81,82],current:[11,24,27,31,39,40,41,44,45,46,50,51,57,58,59,60,71,81,82,83,84,86,88,90,93,94,95,99,103,104,105,106,134,135,136,140,141,142,143,145,146,157,158,163,164,165,166,176,178,185,202,213,221,230,231,233,236,240,242,243,244,247,251,264,266,267,270,272,274,275,279,280,282,288,292],custom:[23,71,91,168,186,212,232],cvs:[249,250,266,272,292,299,300],cwd:12,cycl:[19,21,31,185],cylind:286,daemon:[2,257],dai:[106,221],dap:[2,266,269,273],darwin10:[249,250,266,292,299,300],darwin:6,data:[9,14,20,21,27,28,30,31,43,48,64,69,80,81,82,84,93,95,99,102,105,134,135,136,138,139,147,148,149,150,151,152,156,159,163,165,166,168,169,174,175,176,177,178,181,184,195,200,211,214,216,219,220,224,226,229,232,250,251,261,262,264,265,284,285,286,294,300,302],data_len:285,data_mod:197,data_ord:197,databas:28,databuf:292,datagram:224,datalen:27,datasheet:99,date:[11,68,157,253,274,277,285],datetim:[7,64,78,80,81,82,136,137,139,243,253,277],datetime_pars:[253,277],daunt:259,daylight:106,dbm:[21,27,29],ddress:25,deactiv:229,deal:[90,95,99,140],deb:[57,60,80,83],debian:[4,6],debug:[1,2,4,5,6,7,39,43,47,50,55,57,58,59,62,100,215,216,231,242,247,249,250,254,256,257,266,268,269,270,271,272,273,278,285,286,287,288,289,292,295,296,298,299,300],debug_arduino_blinki:12,debug_arduinoblinki:12,debugg:[5,38,39,55,57,58,59,61,198,249,250,266,269,270,272,273,274,298,299,300],dec:[48,229],decemb:22,decid:[55,86,102,251,285],decim:[22,194],decis:194,declar:[12,94,105,135,190,199,214,226,235,237,246,253,277,279,290,292],decod:[221,224],decompress:264,dedic:[88,99,102,221,229,243,246,249,250,261,299,300],deeper:[90,242,274,286],def:[7,214,231,232,286,292],defaultdevic:82,defin:[1,6,19,20,21,24,27,28,29,31,34,42,43,47,50,53,61,84,85,87,88,90,91,95,103,105,134,135,137,139,140,182,183,190,192,193,212,213,214,216,217,218,219,220,221,227,229,231,232,233,234,236,238,242,246,249,251,253,255,257,259,261,267,274,277,279,280,284,285,286,287,288,291,292,295,297,298,299],defininig:31,defininit:205,definit:[1,12,29,35,37,42,50,61,90,91,99,134,221,230,238,257,261,263,279,284,285,286],defint:231,del:27,delai:[26,84,106,248,251,274],deleg:229,delet:[1,6,10,12,27,35,39,45,49,50,55,57,58,59,61,62,159,175,179,185,244,248,275,284,290,292],delimit:50,deliv:[85,157],delta:[55,81,242],demo:284,demonstr:[20,26,92,165,172,177,274,288,292],denot:90,dep:[1,50,55,61,62,99,136,141,142,157,158,186,187,212,214,221,230,232,243,246,256,268,277,285,286,287,292],depend:[1,4,6,8,20,22,24,27,39,41,49,50,52,55,57,58,59,62,66,85,90,101,107,134,136,157,158,166,185,193,194,207,212,214,221,230,232,233,236,238,240,251,253,254,256,266,277,278,279,282,285,286,288,295,297,298],depict:187,deploi:[43,229,268],deploy:31,deprec:232,depth:[4,101],dequeu:[88,246],deriv:[20,185],desc:[182,183,262],descend:[134,175],describ:[1,2,7,10,11,12,24,28,33,63,95,99,100,102,105,134,138,146,152,157,179,185,193,195,197,206,211,213,214,215,221,229,231,232,238,242,243,252,256,258,263,264,270,273,274,279,285,286,287,288,290,294],descript:[1,7,10,19,27,28,30,55,61,90,93,99,100,101,135,142,145,147,148,149,150,151,152,153,154,155,156,159,160,161,162,163,164,165,166,167,169,170,172,173,174,175,176,177,178,182,183,188,204,205,207,208,209,210,211,212,213,214,217,218,222,223,224,225,226,227,228,230,231,232,233,234,235,236,237,242,244,250,274,275,277,279,280,285,286,300],descriptor:[16,17,27,28,61,166,167,180,182,183,185,261],design:[21,22,23,55,102,103,106,134,179,185,221,229,240,251,253,263,277],desir:[84,90,104,214,253,277,282],desktop:10,destin:[4,31,162,169,172,177,185,194,205,212],detail:[1,10,12,21,22,29,55,95,105,134,135,158,179,194,197,213,214,215,217,218,229,242,243,249,250,256,259,261,263,264,265,266,274,279,292,299,300],detect:[20,55,146,158,179,182,183,198,224,231,232,257],determin:[20,88,90,91,105,134,146,185,221,229,232,241,259,262,279,290],dev:[1,2,3,4,7,8,10,11,12,48,61,66,82,136,140,141,214,215,232,241,242,247,248,254,256,257,260,266,268,269,270,271,272,273,274,278,279,280,281,285,286,287,288,290,292,295,296,298,302],dev_found:257,develop:[3,5,6,7,8,9,13,20,55,59,61,82,90,91,93,95,100,101,102,105,138,140,216,219,221,232,241,247,249,250,251,257,258,261,264,266,267,269,272,273,279,280,284,285,286,291,294,298,299,300,302],devic:[3,4,8,9,14,19,20,21,22,25,28,29,31,32,43,55,64,65,66,67,68,69,70,71,72,73,74,75,76,77,78,80,81,82,102,134,136,138,139,140,141,142,158,180,187,190,193,194,197,216,217,218,219,229,230,231,232,243,249,250,254,255,256,258,259,260,261,263,264,265,266,268,269,270,271,272,273,274,278,284,286,291,292,295,296,297,298,299,300,302],device_id:190,deviceaddr:23,deviceaddrtyp:23,dflt:206,dhcp:[254,278],dhkei:20,diagram:[138,251,270,272],dialog:[12,59,250,300],dictat:[11,62],did:[10,229],diff:285,differ:[4,6,7,8,11,12,20,24,27,30,45,55,57,80,85,90,93,94,95,99,100,101,102,105,140,179,187,193,214,229,230,231,232,235,243,244,246,247,250,251,253,254,256,257,268,269,270,272,275,277,278,279,280,282,284,288,290,292,298,300],differenti:[90,279],difficult:[21,101,134,231],dig:[7,258],digit:[22,140,193,286],dioxid:284,dir:[27,142,158,160,161,162,167,168,170],direct:[10,20,27,194,221,230,280],direct_addr:[264,265],directli:[7,11,14,18,36,158,212,229,232,244,253,254,264,266,275,277,278,287,290],directori:[1,4,6,7,8,10,11,12,34,35,37,41,43,45,50,55,57,59,60,80,82,83,85,88,90,91,92,93,94,99,100,101,103,104,135,140,142,160,161,162,165,166,167,170,171,172,173,175,177,178,196,198,238,242,248,250,253,254,256,257,266,267,269,270,271,272,273,277,278,279,280,285,286,287,288,292,294,295,297,298,300,302],dirent:[142,160,161,162,167,168,170],dirnam:[160,161,162,167,170],dirti:242,disabl:[6,20,22,24,30,84,136,157,185,197,212,214,215,221,229,231,232,243,244,249,254,262,275,278,287,288,289,292,299],disable_auto_eras:141,disallow:[20,179],disbl:221,disc_mod:262,discard:[185,254,278],disciplin:257,disclaim:[7,11,55,256],disconnec:27,disconnect:[27,262],discontigu:134,discov:[22,27,28,257],discover:[27,29,139,219,259,291],discoverable_mod:259,discoveri:[28,138,140,142,257,262,267],discret:[179,180],discuss:[10,90,100,214,229,259,288],disjoint:20,disk:[7,134,146,158,159,173,175,179,180],disk_nam:158,disk_op:142,disk_regist:[142,158],dispatch:[95,232,246],displai:[1,6,22,27,34,35,37,38,39,40,41,42,43,44,45,46,47,48,49,50,51,52,53,54,57,58,59,61,62,64,66,69,71,72,73,76,77,80,81,82,91,140,187,232,257,272,274,285,287,289,294,295,298],displayonli:27,displayyesno:27,dist:[57,80],distanc:[21,230],distinct:22,distribut:[1,4,6,20,21,27,55,107,134,279,285,286],distro:6,div0:67,dive:90,divid:[18,20,67,135,137,179,180,229],dle:27,dll:[269,271,274,286],dm00063382:242,dma:140,dndebug:50,dnrf52:99,do_task:230,doc:[4,6,7,10,23,33,63,252,266,267,270],docker:[3,7,266,302],dockertest:2,document:[1,4,8,12,14,18,20,23,25,59,62,64,99,103,107,143,157,158,168,186,187,190,229,238,242,247,249,250,251,253,254,258,261,263,264,265,266,269,271,277,278,279,288,292,295,296,299,300],doe:[7,20,22,35,50,61,66,71,88,90,95,96,97,99,100,105,134,136,138,140,146,163,167,175,176,179,180,182,185,197,202,212,214,215,217,227,230,231,232,243,244,246,247,251,256,259,266,269,270,271,273,274,275,281,292,297],doesn:[8,10,20,32,134,142,163,175,176,229,233,248,251,256,257,259],doing:[89,106,140,251,261,268,285],domain:2,don:[1,10,31,34,35,37,38,39,40,41,42,43,44,45,46,47,48,49,50,51,52,53,54,57,58,59,62,90,135,143,146,169,177,242,261,263,264,265,279,285,286],done:[6,7,8,23,25,55,81,94,95,99,106,134,136,146,147,166,167,181,202,218,234,235,237,242,243,247,249,250,251,254,257,263,264,265,266,269,270,271,274,278,286,292,299,300],dont:[249,299],doorbel:55,dop:158,doubl:[2,206,272],doubli:185,doubt:263,down:[1,12,61,80,82,229,243,270,272,298],downgrad:[6,7],download:[1,2,4,7,10,12,29,39,41,42,55,58,59,60,70,71,81,82,83,158,202,249,250,252,253,254,256,257,266,269,270,271,272,273,277,278,281,285,292,294,295,296,298,299,300],doxygen:[4,7,85,88,90,91,92,93,94,103,104,135,266,270],doxygengroup:[85,88,90,91,92,93,94,103,104,135],dpidr:273,dpkg:[57,60,80,83],drag:20,drain:24,draw:24,drive:[9,61,106,140,194],driver:[7,55,141,142,158,187,192,193,195,214,216,218,230,249,256,266,269,270,271,272,273,278,288,292,298,299],drop:[10,12,26,185,270,272,298],dsc:261,dsimmon:285,dst:[45,50,70,177,205],dsym:[55,61],dtest:50,due:[20,91,134,141,146,157,266,270,272],dummi:185,dump:[135,249,299],dumpreg:288,duplex:21,duplic:27,durat:[19,27,30,106,261,288],duration_m:[264,265],dure:[20,22,71,86,99,103,134,136,167,185,203,214,229,232,238,251,256,261,268,287,290],duti:[21,31],dwarf:61,dylib:4,dynam:[88,89,91],e407:[272,298],e407_:272,e407_devboard:[53,272,298],e407_devboard_download:272,e407_sch:298,e761d2af:[284,286],e_gatt:263,eabi:[4,7,12,99,107,249,250,266,292,299,300],each:[1,2,10,11,12,19,20,21,22,23,28,32,43,48,49,50,61,62,64,66,73,77,88,91,92,95,99,104,106,134,136,140,160,161,162,167,168,170,172,179,180,181,185,187,193,212,213,215,216,217,218,219,221,225,226,229,230,232,243,246,251,253,261,262,263,264,265,266,277,279,288,290,291,292,302],ead:158,eager:3,earlier:[10,30,57,58,59,80,81,82,175,249,261,264,265,284,285,286,299],eas:141,easi:[1,2,3,8,9,140,187,194,230,231,233,252,269,286,287],easier:[24,99,285],easiest:285,easili:[9,177,216,232,292],east:106,eavesdropp:19,ecdsa256:134,ecdsa:134,echo:[12,60,64,78,80,81,82,83,136,137,139,243,254,278,285,295,296,298],echocommand:12,eck_regist:103,eclips:12,ectabl:[264,265],edbg:[2,266],eddyston:[27,267],eddystone_url:[27,29],edit:[7,100,157,242,244,248,274,275,279,290],editign:252,editor:[59,61,242,248,270],ediv:27,edr:[20,29,257],edu:[249,269,299],ee02:274,eeirili:284,eeprom:141,effect:[104,106,135,158,179,180],effici:[21,31,90,91,185,266],eid:264,eight:[138,174],einval:84,eir:29,eir_len:257,either:[1,4,6,11,21,27,29,30,57,59,61,80,85,86,90,91,135,136,137,143,146,172,194,229,232,233,236,237,243,264,265,274,285,286,294],elaps:[20,84,106],electron:302,element:[39,53,55,57,58,59,85,88,90,91,94,103,104,105,134,135,145,146,147,148,151,153,154,185,206,221,251],elev:94,elf:[7,12,34,38,48,55,61,71,229,242,243,249,250,253,254,256,257,260,266,268,269,270,271,272,273,274,277,278,285,286,288,292,295,296,298,299,300],elfifi:71,elicit:229,els:[23,86,103,134,160,161,162,167,170,185,215,229,249,284,285,286,299],elsewher:[258,261,279],emac:285,email:[3,241,302],emb:141,embed:[1,3,4,12,39,55,57,58,59,107,134,179,197,241,242,249,250,266,272,292,299,300],emit:[55,61],emploi:21,empti:[50,93,105,146,173,185,232,236,253,255,263,277],emptiv:9,emul:[254,274,278,290],enabl:[1,8,9,24,30,31,32,34,35,37,38,39,40,41,42,43,44,45,46,47,48,49,50,51,52,53,54,55,57,58,59,62,73,76,77,78,88,97,99,135,136,137,138,140,141,157,187,197,201,212,214,215,216,218,219,220,226,231,232,242,246,247,249,250,256,259,262,267,276,283,284,285,286,290,294,297,299,300,302],enc:[205,207,208,210],enc_chang:262,encapsul:21,encod:[7,51,136,138,139,207,208,209,210,219,221,225,253,274,277,287,291,292],encoding_cborattr:229,encoding_tinycbor:229,encompass:[14,20],encount:[7,10,20,57,90,156,185,251],encourag:140,encrypt:[20,22,27,30,179,260,262],encrypt_connect:20,end:[9,20,28,30,55,134,146,164,174,176,185,211,232,240,255,256,274,285],endian:[23,61,90,134,274],endif:[226,230,232,239,240,253,268,277,285,286,292],energi:[9,21,22,90,267,302],english:134,enjoi:286,enough:[55,90,102,134,162,202,205,285],enqueu:[92,199],ensur:[11,12,21,59,99,103,106,107,162,187,194,229,230,231,232,243,246,247,251,254,257,261,267,278,279,280,288,291,294,297],entail:229,enter:[12,22,47,99,221,227,228,230,251,266,268,270,288,292],entir:[2,99,134,179,180,185,251,263,285],entireti:177,entiti:[43,258],entri:[20,22,72,135,146,147,148,151,154,156,160,161,162,167,170,177,179,180,185,211,215,221,226,229,263,289],enumer:[134,190,198,213],environ:[3,4,9,12,55,58,59,61,82,102,107,140,197,240,257,296],eof:[57,80],ephemer:264,epoch:106,equal:[29,72,90,185,212,231,232,233],equat:29,equival:[46,61,141,166,187,286,302],eras:[10,71,134,141,142,146,155,179,180,183,185,191,266,270,271,272,274,286],erase_sector:272,err:[103,165,211,215,224,225,230,284,286],error:[1,2,4,6,7,20,21,26,34,35,37,38,39,40,41,42,43,44,45,46,47,48,49,50,51,52,53,54,57,58,59,62,80,82,84,90,95,99,103,141,142,159,160,161,162,163,165,166,167,169,170,172,173,174,175,176,177,178,179,182,183,184,215,229,232,253,254,259,261,262,263,266,269,270,272,273,274,277,278,280,284,285,286,287,290,292,298],error_rsp_rx:[76,243],error_rsp_tx:[76,243],error_stat:230,escap:[249,254,278,292,299],especi:106,essenti:[43,61,232,251],establish:[20,27,78,243,246,259,260,262,269,271,274,286],etc:[1,21,24,26,36,43,57,80,90,91,95,101,102,134,138,140,187,189,200,204,251,255,262,285,286],ethernet:[140,187],etyp:286,eui:274,eul:288,euler:288,ev_arg:[88,103,136],ev_cb:[88,136,246],ev_next:88,ev_queu:88,eval:[271,286],evalu:[12,84,106,231,232,271,274,279,286],evalut:106,even:[4,10,84,93,102,134,157,185,206,218,229,284,286,290],event:[20,24,25,27,85,92,95,103,105,136,140,212,218,221,223,230,232,243,251,257,259,260,264,265,284,285,286,290,292,302],event_q:286,event_queu:136,eventq:[92,284,285],eventq_exampl:246,eventu:[4,105,106,185],ever:[90,134,146],everi:[1,32,61,103,104,105,140,156,185,262,264,266,268,280,285,292],everyon:[10,251],everyth:[1,90,99,103,229,251,253,254,277,278,285],evq:223,evq_list:88,evq_task:88,exact:[102,134,193,230],exactli:[93,99,104,163,176,232],examin:[193,199,259,261,296],exampl:[1,2,3,6,7,9,12,22,23,24,25,30,31,55,57,58,59,60,61,62,64,80,82,83,84,88,90,91,92,93,94,99,100,102,103,104,105,106,107,134,136,139,158,179,180,186,190,194,195,212,214,215,216,217,221,226,229,230,241,242,243,249,250,251,253,254,255,257,258,262,266,268,270,274,277,278,279,280,281,285,287,288,289,290,291,292,295,296,298,299,300,302],example1:90,example2:90,exce:[185,222,226,249,299],exceed:20,except:[7,51,90,134,230,259,264,265,285,286],excerpt:[136,213,214,215,226,231,232,261,263,290],exchang:[14,21,22,27,28],excit:[7,242,256],exclud:[51,134,229,288],exclus:[22,94,104,213],exe:[12,59,60,82,83],exec_write_req_rx:[76,243],exec_write_req_tx:[76,243],exec_write_rsp_rx:[76,243],exec_write_rsp_tx:[76,243],execut:[1,2,7,11,12,30,34,35,37,38,39,40,41,42,43,44,45,46,47,48,49,50,51,52,53,54,55,57,58,59,61,62,67,80,82,86,88,95,99,102,105,107,139,142,143,145,197,202,223,232,236,238,239,243,251,253,259,261,262,263,264,265,268,277,285],exhaust:[20,103,146,185],exisit:27,exist:[2,10,20,24,29,41,46,49,50,71,100,146,152,157,163,165,166,167,172,173,175,176,178,179,182,183,185,193,213,215,220,232,235,248,249,250,254,260,266,269,270,271,272,273,278,280,285,286,287,289,290,291,292,294,295,297,298,299,300,302],exit:[8,80,249,269,271,274,285,286,299],expect:[6,20,43,61,85,95,99,103,135,136,140,229,233,234,235,236,237,251,253,257,264,265,274,277],experi:[22,244,275,288],expertis:279,expir:[84,85,88,199,246],expire_msec:201,expire_sec:201,expiri:[85,199],explain:[4,12,104,243,254,255,256,257,264,265,267,278,280,294,297,302],explan:[34,35,37,38,39,43,44,45,46,47,48,50,51,53,54,65,66,67,68,69,70,71,72,73,74,75,76,77,158,259],explanatori:[30,100,264,265],explic:288,explicit:[253,277],explicitli:259,explor:[134,229,261,294],expos:[1,14,21,95,139,179,180,181,216,221,232,258,263],express:[23,174,232,233,263,285,286],ext:[12,270],ext_bynam:218,ext_bytyp:218,extend:[20,29,30,286,289,291],extended_dur:27,extended_period:27,extens:[21,30,143,274],extent:[249,250,266,292,299,300],extern:[12,29,40,99,103,140,141,181,187,193,212,230,238,249,250,279,280,286,299,300],extra:[38,42,47,140,158,247,249,252,259,292,299],extra_gdb_cmd:61,extract:[4,11,58,59,60,82,83,242,269],extrajtagcmd:[38,42,47],extrem:9,eyes:233,f401re:53,f411a55d7a5f54eb8880d380bf47521d8c41ed77fd0a7bd5373b0ae87ddabd42:295,f4discoveri:270,f_activ:146,f_active_id:146,f_align:146,f_close:[168,186],f_closedir:[168,186],f_dirent_is_dir:[168,186],f_dirent_nam:[168,186],f_filelen:[168,186],f_getpo:[168,186],f_magic:146,f_mkdir:[168,186],f_mtx:146,f_name:[168,186],f_oldest:146,f_open:[168,186],f_opendir:[168,186],f_read:[168,186],f_readdir:[168,186],f_renam:[168,186],f_scratch:146,f_scratch_cnt:146,f_sector:146,f_sector_cnt:146,f_seek:[168,186],f_unlink:[168,186],f_version:146,f_write:[168,186],face:229,facil:[19,107,238,246],fact:[141,279],factor:9,factori:273,fail:[20,42,57,80,103,146,149,166,167,179,185,233,234,235,237,249,253,256,262,269,270,273,274,277,279,286,299],fail_msg:233,failov:229,failur:[20,103,134,142,147,148,149,151,152,154,155,156,158,159,160,162,163,165,166,169,172,173,174,175,176,177,178,182,183,184,222,224,225,226,233,239,240,253,261,262,263,277],fair:90,fairli:[24,55,61,90,104],fall:[102,107,302],fallback:27,fals:[229,231,233],famili:[4,107,141,157,257],familiar:[3,12,232,242,243,249,255,256,258,285,286,292,299,302],fanci:105,faq:[11,13],far:[256,292],fashion:[95,146,185,242],fast:285,fat2n:[7,61],fatf:[7,142,157,158],fault:136,favorit:[242,248],fcb:[7,135,147,148,149,150,151,152,153,154,155,156,212],fcb_append:[146,148,149],fcb_append_finish:[146,147],fcb_append_to_scratch:147,fcb_entri:[146,147,148,151,156],fcb_err_nospac:147,fcb_err_novar:151,fcb_getnext:146,fcb_init:146,fcb_log:212,fcb_rotat:[146,147],fcb_walk:146,fcb_walk_cb:156,fda_id:185,fe80:[249,299],fe_area:[146,151,156],fe_data_:146,fe_data_len:[146,151,156],fe_data_off:[146,151,156],fe_elem_:146,fe_elem_off:146,feat:286,featur:[1,3,11,19,20,30,91,102,105,146,158,179,221,229,232,241,259,274,288,294],feedback:[242,248,267,286],feel:3,femal:298,fetch:[1,12,40,57,80,243,246,247,257,267,279,280,285,294,297],few:[1,6,14,25,31,55,61,91,99,100,230,253,256,261,264,274,277,286,302],ffconf:157,ffffffff:272,ffs2nativ:[7,61],fhss:21,ficr:23,fictiti:[279,280],fie_child_list:185,field:[20,27,86,88,90,99,134,136,181,194,207,209,213,214,215,221,226,229,230,232,259,261,263,264,265,279,280,288,290],fifo:146,figur:[90,134,135,146],file:[1,2,4,6,7,10,11,12,34,36,37,41,43,46,48,50,55,57,58,59,60,61,64,70,71,80,81,82,83,100,101,102,107,134,135,136,140,179,190,193,195,202,212,213,214,217,218,221,229,231,232,236,238,242,243,244,246,248,250,252,253,254,256,257,263,266,268,269,270,272,273,274,275,277,278,279,281,285,286,288,296,300],file_nam:61,filenam:[1,34,35,37,38,39,40,41,42,43,44,45,46,47,48,49,50,51,52,53,54,57,58,59,62,70,71,99,157,162,166,168,172,175,179,185,229,257,285],filesystem:[55,135,157,202],fill:[10,48,101,146,147,149,151,152,205,206,253,256,261,264,265,277,285,286],filter:[2,22,27,30,72,266],find:[1,2,3,20,28,34,55,61,85,88,90,91,92,93,94,100,102,103,104,135,152,187,218,230,231,235,241,242,249,250,254,256,257,266,269,270,273,278,292,295,298,299,300,302],find_info_req_rx:[76,243],find_info_req_tx:[76,243],find_info_rsp_rx:[76,243],find_info_rsp_tx:[76,243],find_type_value_req_rx:[76,243],find_type_value_req_tx:76,find_type_value_rsp_rx:76,find_type_value_rsp_tx:76,fine:[9,264,265],finish:[4,104,147,185,274,285],fip:21,fire:[85,201,251,260,292],firmwar:[134,158,243,249,250,269,271,274,278,285,286,299,300],first:[2,3,6,8,12,21,22,29,33,57,58,59,60,63,82,83,84,85,90,91,94,99,105,107,134,135,146,174,179,180,185,186,190,204,206,218,221,229,232,242,243,251,254,255,258,259,260,261,263,264,265,267,268,274,278,284,285,286,288,292,294,297,302],fit:[4,177,185,244,259,260,275],five:[20,21,22,163,176,243],fix:[6,10,11,91,106,134,281],fl_area:147,fl_data_off:147,flag:[1,6,12,27,29,55,57,58,59,61,62,64,80,81,82,90,100,134,166,229,247,257,261,263,284,285,288,295,298],flash0:158,flash:[1,9,39,43,48,55,57,58,59,61,101,102,135,140,147,148,152,158,180,182,183,186,187,191,192,193,195,202,212,229,232,243,244,266,270,271,272,274,275,286],flash_area:[146,156],flash_area_bootload:[99,134,182,183,231,232],flash_area_image_0:[99,134,182,183],flash_area_image_1:[99,134,182,183,232],flash_area_image_scratch:[99,134,182,183,231],flash_area_nff:[182,183,231,232],flash_area_noexist:231,flash_area_read:[146,151,156],flash_area_reboot_log:[231,232],flash_area_to_nffs_desc:[182,183],flash_area_writ:[146,147],flash_area_x:146,flash_id:141,flash_map:[7,135,182,183,231,232],flash_map_init:232,flash_own:[231,232],flash_spi_chip_select:193,flash_test:[7,136],flat:[90,206,212],flavor:266,flexibl:[90,102,241,259,279,280],flg:285,flight:90,float_us:287,flood:31,flow:[21,136,257,264,265],fmt:136,focu:251,folder:[4,10,12,33,55,59,63,248,269],follow:[1,2,3,4,6,7,8,10,11,12,19,20,21,23,24,26,27,29,30,31,32,37,38,43,50,51,55,57,58,59,60,61,64,66,67,71,72,73,77,78,80,81,82,83,87,88,90,92,93,94,99,100,102,104,105,106,107,134,136,137,139,140,141,142,146,158,166,173,174,175,179,180,181,185,186,187,194,196,197,207,209,212,213,214,215,216,218,219,229,230,231,232,233,234,235,236,237,238,242,243,246,247,248,251,253,254,256,257,258,259,261,263,264,265,266,267,268,269,270,271,272,273,274,277,278,279,280,281,284,285,286,287,288,289,290,291,292,294,295,297,298],foo:135,foo_callout:135,foo_conf_export:135,foo_conf_set:135,foo_val:135,footer:[134,268],footprint:[9,138,140],fop:171,fopen:166,forc:[41,49,52,90,229],forev:[105,166,167,240],forgeri:22,forget:[80,166,167,242,284,285,286],forgot:285,fork:10,form:[1,19,22,23,26,66,90,92,105,185,232,253,261,262,264,274,277,279],formal:[7,20],format:[8,29,50,66,68,71,72,90,136,138,157,158,179,182,183,204,205,206,213,230,232,233,236,254,257,264,268,278,279,280,288,295,298],former:185,formula:[3,60,83],forth:[135,206],fortun:55,forver:27,forward:259,found:[1,20,33,55,63,91,99,154,179,185,206,257,262,263,264,266,270,272,298],foundat:[4,21,31,138,249,250,266,272,279,285,286,292,299,300],four:[19,22,47,134,174,178],fraction:[106,253,277],frame:[221,224,225,251,274],framerwork:137,framework:[21,28,103,138,213,219,220,238,239,257,287,288,289,292,293,294],frdm:53,free:[2,4,73,88,89,90,91,146,185,222,226,229,249,250,260,262,266,272,292,296,299,300],freebsd:107,freed:[91,185],freedom:[262,264,265],frequenc:[21,24,84,87,99,103,106,140,187,196,201,230,251,274],frequent:[10,19,21,22,103,264,265,292],friend:31,friendli:140,from:[1,4,6,7,8,9,10,11,12,19,20,22,23,26,27,30,31,32,35,36,38,39,41,43,44,45,46,47,49,50,51,55,56,60,61,62,64,65,66,68,69,70,71,72,73,76,77,79,83,84,85,86,88,89,90,91,92,93,94,95,99,100,101,102,103,104,105,106,107,134,135,137,138,139,141,142,143,145,146,152,158,159,160,161,162,166,167,168,169,170,172,174,175,177,182,183,185,186,194,202,205,206,212,213,214,215,216,217,218,219,220,221,223,224,229,230,231,232,233,234,235,237,238,240,242,243,246,247,249,250,251,253,254,255,256,257,258,261,262,263,264,265,266,267,268,269,270,271,272,273,274,277,278,279,280,285,286,288,292,294,295,296,298,299,300],front:185,fs_access_append:166,fs_access_read:[159,166,169,174],fs_access_trunc:[163,166,172,175,176],fs_access_writ:[163,166,172,175,176],fs_cli:7,fs_cli_init:222,fs_close:[163,166,169,172,174,175,176,177,178],fs_closedir:[142,167],fs_dir:[158,160,161,162,167,168,170],fs_dirent:[7,158,160,161,162,167,168,170],fs_dirent_is_dir:[160,162,167,170],fs_dirent_nam:[142,160,161,167,170],fs_eaccess:173,fs_ealreadi:178,fs_ecorrupt:[173,182,183],fs_eempti:173,fs_eexist:[171,173],fs_eful:173,fs_ehw:173,fs_einval:173,fs_enoent:[142,160,161,162,167,170,172,173],fs_enomem:173,fs_eo:173,fs_eoffset:173,fs_eok:173,fs_eunexp:173,fs_euninit:173,fs_fcb:229,fs_file:[7,158,159,163,164,166,168,169,172,174,175,176],fs_filelen:176,fs_if:[168,186],fs_ls_cmd:222,fs_ls_struct:222,fs_mkdir:[7,178],fs_mount:7,fs_name:158,fs_nmgr:7,fs_op:[171,186],fs_open:[159,163,169,172,174,175,176,177,178],fs_opendir:[142,160,161,162,170],fs_read:[159,166,174,177],fs_readdir:[142,160,161,162,167],fs_regist:186,fs_unlink:165,fs_write:[163,172,178],fssl:[11,58],fsutil:[7,158],fsutil_r:158,fsutil_w:158,ftdichip:257,fulfil:261,full:[1,7,8,20,21,28,30,48,55,99,134,135,141,147,162,166,172,173,185,202,212,221,229,231,232,243,248,256,259,262,263,268,285,286,288,292,302],fuller:185,fulli:[9,21,134,179,180,185,229,256,265,279,280,286],fun:[242,285],func:[103,135],fundament:[1,302],funtion:206,further:[6,99,103,194],furthermor:[95,134,179,180,185,229,251,264,265],fuse:55,futur:[93,185,213,221,232,274,279,280,281],g_bno055_sensor_driv:215,g_bno055stat:215,g_current_task:84,g_led_pin:[248,251,268],g_mbuf_buff:90,g_mbuf_mempool:90,g_mbuf_pool:90,g_mystat:230,g_nmgr_shell_transport:224,g_os_run_list:[84,86],g_os_sleep_list:[84,86],g_os_start:84,g_os_task_list:84,g_stats_map_my_stat_sect:230,g_task1_loop:268,gain:[94,104,186,256,286],gap:[18,19,20,21,30,185,258,261,263,285,286,287],garbag:146,gatewai:274,gatt:[14,18,21,27,30,31,32,258,261,263,285,286,287],gatt_acc:261,gatt_adc_v:286,gatt_co2_v:284,gatt_co2_val_len:284,gatt_srv:286,gatt_srv_sns_access:286,gatt_svr:[263,284,286,288],gatt_svr_chr_access_gap:[261,263],gatt_svr_chr_access_sec_test:[263,284],gatt_svr_chr_sec_test_rand_uuid:[263,284],gatt_svr_chr_sec_test_static_uuid:[263,284],gatt_svr_chr_writ:[284,286],gatt_svr_register_cb:263,gatt_svr_sns_access:[284,286],gatt_svr_svc:[261,263,284],gatt_svr_svc_adc_uuid:286,gatt_svr_svc_co2_uuid:284,gatt_svr_svc_sec_test_uuid:[263,284],gaussian:21,gavin:58,gc_on_oom_test:[253,277],gc_test:[253,277],gcc:[4,7,57,107],gcc_startup_:99,gcc_startup_myboard:99,gcc_startup_myboard_split:99,gcc_startup_nrf52:[99,269,271,292],gcc_startup_nrf52_split:[269,271,273,274,292],gdb:[4,7,12,38,47,61,62,99,249,250,251,256,266,268,269,270,272,273,286,292,299,300],gdb_arduino_blinki:12,gdbmacro:7,gdbpath:12,gdbserver:6,gear:107,gen:[27,30],gen_task:246,gen_task_ev:246,gen_task_prio:246,gen_task_stack:246,gen_task_stack_sz:246,gen_task_str:246,gener:[1,11,15,16,17,18,19,20,21,23,27,28,29,31,34,35,43,55,61,62,85,88,90,91,94,99,105,134,142,179,180,193,206,229,231,234,235,237,242,243,247,248,249,250,251,252,253,254,256,257,259,260,263,264,265,266,267,268,269,270,271,272,273,274,277,278,279,284,285,288,292,295,298,299,300],get32:84,get:[2,4,6,7,8,9,10,11,23,55,56,58,59,60,61,64,76,79,81,82,83,86,90,94,95,99,101,102,103,105,106,134,135,139,140,146,156,163,166,169,172,177,185,193,206,213,217,219,229,232,233,242,246,248,251,253,254,255,257,259,261,263,264,265,266,267,269,270,272,273,274,277,278,284,285,286,291,292,298,302],gettng:[244,275],gfsk:21,ggdb:6,ghz:[21,254,278],gist:[140,193],gister_li:217,git:[11,55,58,80,81,82,107,254,266,278,279,280,281],github:[1,7,10,11,33,55,57,58,59,63,80,81,82,107,190,242,254,266,278,279,280,281,285,286,294],githublogin:281,githubpassword:281,githubusercont:[11,57,58,59,80,81,82],give:[55,193,229,242,251,256,264,265,274,279,280,286],given:[12,20,42,84,91,102,105,106,134,142,145,151,152,158,206,213,217,218,251,280],glanc:259,glibc:57,global:[1,29,62,90,91,94,181,212,213,215,230,238,261,285],gnd:[8,274,286,288,298],gnu:[3,4,12,38,47,249,250,266,270,272,273,292,299,300],goal:[55,107,297],gobjcopi:6,gobjdump:6,gobl:81,goe:[61,238,253,277,285],going:[102,229,264,268,285,286],golang:[11,59,82],gone:260,good:[7,9,22,55,94,99,103,134,157,229,256,259,265,274,285],googl:[264,294],gopath:[11,57,58,59,60,80,81,82,83],got:[284,285,286],govern:[285,286],gpg:[57,80],gpio:[8,102,140,193,195,197,246],gpio_ev:246,gpio_l:246,gpl:[4,249,250,266,270,272,273,292,299,300],gplv3:[249,250,266,272,292,299,300],gpo:187,grab:89,gracefulli:240,graduat:286,grain:9,graph:[1,50,62,286],graviti:288,great:[8,21,134,231,248,285,286],greater:[21,29,90,185,231],greatest:[134,185],green:[2,10,12,254,266,270,271,278,288,295],grid:55,ground:[286,288],group:[2,10,20,76,137,140,221,230,232,243,274],grow:[53,251],guarante:[91,93],guard:95,guid:[7,11,12,18,59,62,64,82,215,216,232,243,244,246,251,253,258,263,265,275,277,279,295,298],guinea:252,gyro:288,gyro_rev:288,gyroscop:[213,288],h_mynewt_syscfg_:232,hack:[7,9,12,242,248,286],had:[90,95,134,229],hal:[1,7,9,48,55,61,87,101,140,141,182,183,186,187,194,197,199,215,246,256,266,270,272,286,288,292,302],hal_bsp:[7,99,140,192,214,266,269,270,272,285,290],hal_bsp_flash_dev:[99,141,192],hal_bsp_init:214,hal_common:[7,256,270,272],hal_flash:[7,99,141,158,192,266,270,272],hal_gpio:[7,142,190,246],hal_gpio_init_out:[105,246,248,251,268],hal_gpio_irq_en:246,hal_gpio_irq_init:246,hal_gpio_pull_up:246,hal_gpio_toggl:[105,246,248,268],hal_gpio_trig_ris:246,hal_gpio_writ:[190,251],hal_i2c_begin:194,hal_i2c_end:194,hal_i2c_init:194,hal_i2c_master_data:194,hal_i2c_master_read:194,hal_i2c_master_writ:194,hal_i2c_prob:194,hal_i2c_read:194,hal_i2c_writ:194,hal_os_tick:[269,292],hal_reset_caus:[198,290],hal_rtc:157,hal_spi:142,hal_spi_config:197,hal_spi_dis:197,hal_spi_en:197,hal_spi_init:[142,197],hal_spi_set:[141,197],hal_system_start:198,hal_tim:[84,87],hal_timer_cb:[84,199],hal_timer_set_cb:199,hal_timer_start:199,hal_timer_start_at:199,hal_uart:285,hal_uart_blocking_tx:200,hal_uart_config:285,hal_uart_flow_ctl_non:285,hal_uart_init_cb:285,hal_uart_parity_non:285,hal_uart_start_tx:285,hal_watchdog_en:201,hal_watchdog_init:201,hal_watchdog_tickl:201,hal_xxxx:187,half:[16,17,99,106],halfwai:134,halt:[95,196,266,270,272],hand:[229,242,251,253,277],handbook:[269,273],handi:[99,286],handl:[17,20,27,28,30,61,90,92,107,140,141,142,158,159,160,161,162,166,167,170,175,176,177,178,185,212,216,217,221,243,246,260,261,262,284,285,286,292],handler:[88,95,99,137,217,219,222,224,226,227,246,251,284,285,286,287],happen:[9,20,26,135,146,185,254,260,263,264,265,266,278,280],happi:[7,9],har:298,hard:[103,136],hardcod:[25,27],hardwar:[2,3,5,6,7,9,20,21,24,25,31,34,84,87,99,101,102,134,140,179,180,185,189,190,191,192,193,194,196,198,199,200,201,215,229,232,244,246,251,254,256,257,264,265,266,268,269,270,271,275,278,279,285,292,302],harm:134,has:[2,3,4,7,10,11,12,20,22,24,26,30,34,36,43,50,55,57,58,59,61,62,77,80,81,82,84,86,88,89,90,91,95,97,98,99,102,103,104,105,134,135,136,138,140,144,146,158,159,171,175,179,185,193,197,200,202,215,217,229,230,232,238,240,243,247,249,250,251,252,253,254,261,262,263,266,268,269,270,274,277,278,279,280,284,285,291,292,299,300,302],hash:[34,37,43,46,71,134,185,229,247,295,298],have:[1,2,3,6,7,8,9,11,12,19,20,22,24,30,32,43,50,52,54,55,57,58,59,60,61,62,64,80,81,82,83,85,88,90,91,95,99,101,102,103,104,105,107,134,136,138,140,141,143,146,149,179,180,185,187,192,193,199,221,227,229,230,231,232,241,242,243,246,247,248,249,250,252,253,254,255,256,257,260,261,263,264,265,266,267,268,269,270,271,272,273,274,277,278,279,280,282,284,285,286,287,288,289,290,291,292,294,295,296,297,298,299,300,302],haven:[3,142,241,280,285,286,302],hci1:257,hci:[21,255],hci_adv_param:259,hci_common:243,hdr:[134,233],hdr_ver:204,head:[11,58,80,81,82,88,94,104,217,252],header:[1,37,39,46,55,57,58,59,61,99,134,138,146,147,185,190,193,212,214,232,238,243,268,285,286],heading1:252,heading2:252,heading5:252,headless:2,health:264,heap:[91,95,99],heart:251,held:279,hello:[12,69,163,176,200,243,254,267,278,295,296,298,302],help:[1,8,12,31,34,35,37,38,40,41,42,43,44,45,46,47,48,49,50,51,52,53,54,57,58,59,62,64,65,67,68,69,70,71,72,73,74,75,76,77,80,81,82,95,100,101,106,140,206,226,229,231,244,249,250,251,252,253,255,256,259,266,268,269,271,274,275,277,278,281,285,286,288,292,299,300],helper:[1,61,100,141,264,265],henc:[134,241],her:95,here:[1,3,8,10,11,29,32,55,73,76,77,88,90,91,93,99,100,103,135,136,146,162,163,166,169,177,179,193,206,212,213,215,221,229,230,231,232,239,241,242,246,252,253,254,257,261,263,264,265,266,268,269,270,273,274,277,278,279,280,285,286,296,302],hertz:84,hex:[7,37,43,48,71,194,229,272,274,284,292],hexidecim:66,hfxo:24,hidapi:4,hidraw:4,hierarchi:[158,232,238],high:[9,18,21,64,87,104,140,246,249,251,299],high_duti:27,higher:[11,14,20,21,55,58,59,72,80,81,82,94,95,104,105,187,212,218,231,232,241,251,253,257,277,280],highest:[84,86,94,95,97,105,231,232,251],highli:241,highlight:[2,6,30,107,242,254,266,269,271,273,278,286,287,292],hint:55,his:95,histori:231,hit:[36,268],hl_line:[214,215,254],hog:251,hold:[33,43,63,90,91,93,162,205,215,221,242,251,274,279,286],hole:[185,286],home:[7,11,59,99,229,253,256,268,277,281,285],homebrew:[4,6,7,11,36,56,60,79,83],homepag:[1,43,61,136,277,285,286],hook:[103,272,285,298],hop:[21,140],host:[7,9,21,22,23,26,29,30,66,70,71,88,90,134,219,249,250,252,253,254,256,257,261,262,263,266,277,278,285,286,287,291,292,299,300],hotkei:[249,299],hour:106,how:[2,3,4,5,6,7,8,11,12,20,21,23,30,55,57,58,59,60,66,80,81,82,83,88,92,93,94,99,102,103,106,134,135,136,146,152,154,172,179,193,197,207,212,214,215,226,229,230,233,236,238,241,242,243,247,248,251,252,253,254,255,256,257,260,261,262,264,265,266,267,268,269,270,271,272,273,274,276,277,278,284,285,286,288,289,291,292,294,295,296,297,298,302],how_to_edit_doc:252,howev:[3,57,80,90,102,105,107,134,136,179,185,193,230,247,269,279],htm:257,html:[4,33,63,158,249,250,253,266,270,272,292,299,300],http:[1,4,10,11,12,33,39,55,57,58,59,61,63,80,81,82,107,136,143,190,242,249,250,257,264,266,269,270,272,273,277,279,281,285,286,292,298,299,300],httperror404:[57,80],hub:[254,278],human:[257,279],hw_bsp_nativ:61,hw_drivers_nimble_nrf51:229,hw_hal:55,hw_mcu_nordic_nrf51xxx:229,hypothet:20,i2c:[8,140,141,187,194,288,289,292],i2c_0:[287,288,289,292],i2c_0_itf_bno:214,i2c_0_itf_li:214,i2s:266,i2s_callback:266,i386:[4,6],iOS:[260,284,286,287,289,291,294],ibeacon:[23,256,267,302],icon:[10,12],id16:263,id3:[33,63],id_init:232,idcod:266,idea:[61,93,94,103,259],ideal:21,ident:[18,20,22,23,27,30,66,107,139,229,230,238],identifi:[1,8,19,20,27,29,34,71,99,134,135,185,194,254,264,265,269,271,274,278,286,295,298],idl:[27,77,96,103,251,256,285,295,298],idx:[27,141,185],ietf:206,if_rw:139,ifdef:[229,232,239,268,292],ifndef:[232,285,286],ignor:[6,27,82,158,172,179,232,249,299],ih_flag:134,ih_hdr_siz:134,ih_img_s:134,ih_key_id:134,ih_mag:134,ih_tlv_siz:134,ih_ver:134,iii:134,illustr:[12,90,94,95,134,251,286,292],imag:[2,6,7,12,31,34,38,39,42,43,47,55,57,58,59,61,64,78,80,81,82,99,100,102,107,136,137,203,204,205,207,208,210,230,231,241,244,249,250,256,260,266,267,268,275,284,285,296,297,299,300,302],image_ec256:[254,266,269,270,271,272,273,274,278,288,295,296,298],image_ec:[7,254,266,269,270,271,272,273,274,278,288,295,296,298],image_f_ecdsa224_sha256:134,image_f_non_boot:134,image_f_p:134,image_f_pkcs15_rsa2048_sha256:134,image_f_sha256:134,image_head:134,image_header_s:134,image_mag:134,image_magic_non:134,image_ok:134,image_rsa:[7,254,266,269,270,271,272,273,274,278,288,295,296,298],image_tlv:134,image_tlv_:134,image_tlv_ecdsa224:134,image_tlv_rsa2048:134,image_tlv_sha256:134,image_valid:[7,254,266,270,271,273,278,288,295,296,298],image_vers:[134,204,205],img:[37,46,71,242,243,247,248,249,250,254,256,257,260,266,269,270,271,272,273,274,278,285,288,292,295,298,299,300],img_data:211,imgmgr:[7,136,137,158,202,232,243,286],imgmgr_max_ver_str:205,imgmgr_module_init:232,imgr_list:[207,208,210],imgr_upload:211,imgr_ver_jsonstr:205,immedi:[26,99,134,175,185,197,252,259,264,265],impact:[24,185],impl:61,implemen:66,implement:[9,10,21,32,61,66,88,90,91,93,99,101,102,134,135,136,137,157,158,179,185,187,190,192,193,194,195,196,198,202,206,213,214,216,218,220,221,227,232,238,246,253,258,261,263,264,274,277,286,287,288,292],impli:[253,264,265,277,280,285,286],implicit:[253,277],impos:[134,179,180,185],imposs:[19,181],impract:263,impress:286,improv:268,imuplu:288,inc:[4,249,250,266,272,292,299,300],includ:[1,4,7,9,10,14,15,16,17,19,20,21,22,26,27,28,31,43,50,59,61,84,90,99,101,102,134,136,139,140,141,142,144,157,158,159,160,161,162,163,164,165,166,167,168,169,170,171,172,173,174,175,176,177,178,179,180,181,182,183,184,185,186,187,189,190,197,200,202,212,213,214,217,218,219,221,229,231,232,238,242,243,246,247,249,251,253,257,258,259,261,264,265,269,277,279,280,285,286,287,288,290,291,292,297,299],include_tx_pow:27,incom:[20,88,202,221,222,224,246],incompat:[57,80,279],incomplet:[29,99,165],incomplete_block_test:[253,277],incorrect:[42,106],increas:[21,22,185,221,222,226,232,249,251,299],increasin:146,increment:[92,106,135,185,230],incub:[7,55,190,232,242,286],inde:[95,272],indefini:[264,265],indent:6,independ:[22,102,134,140,187,189,191,193,194,196,198,199,200,201,232,285],indetermin:[253,277],index:[31,72,134,257],indian:106,indic:[7,10,19,20,26,28,29,30,88,98,99,103,134,136,138,158,164,166,173,185,193,194,211,218,221,226,229,231,232,247,253,254,261,263,266,269,270,273,277,278,292,294],indirect:286,individu:[11,134,135,140,193,232,237,243,279],industri:[21,157],ineffici:185,infinit:[88,95,232,251,268],info:[39,57,58,59,61,64,65,66,67,68,69,70,71,72,73,74,75,76,77,80,81,82,146,147,151,226,247,262,266,270,272,273,278,284,286],inform:[1,6,7,12,20,22,23,27,29,34,37,39,40,57,58,59,61,62,64,66,71,80,81,82,88,90,91,99,101,102,105,134,138,139,151,185,212,213,215,216,226,229,230,232,241,242,246,247,250,251,256,259,262,263,264,265,266,268,274,279,280,281,285,286,288,292,295,298,300],infrastructur:256,ing:[140,264,265],inher:[1,23,261],inherit:[1,4,59,94,181,213],ininclud:230,init:[50,55,84,214,218,232,285,286],init_app_task:95,init_func_nam:232,init_funct:232,init_stag:232,init_task:[246,251],init_tim:[268,292],initi:[16,19,21,23,25,26,27,28,61,84,85,87,88,90,91,92,94,95,96,97,99,103,104,105,135,136,140,144,152,158,173,182,183,184,185,187,189,191,193,194,196,197,199,201,203,206,210,212,214,217,218,219,221,222,226,238,239,243,246,248,253,257,258,262,264,265,268,277,284,285,286,287,288,292],initialis:[215,266],inod:[179,181],inoper:[26,264,265],input:[20,22,27,140,187,193,246,249,253,272,277,299],inquiri:[20,29],insert:185,insid:[24,90,95,167,253,268,272,277],insight:[140,251],inspect:[48,134,135,262],instal:[3,7,9,33,39,54,55,63,78,95,99,100,142,217,243,246,247,248,249,251,253,254,255,256,257,266,267,269,270,271,272,273,277,278,280,282,285,287,288,289,291,292,294,295,296,297,298,299,302],instanc:[2,3,9,27,62,90,181,182,183,185,212,230,259,264,265,266],instant:20,instantan:251,instanti:[95,140],instantli:104,instead:[7,11,12,24,88,104,134,136,229,232,243,246,253,260,266,268,269,270,271,272,273,277,281,284,285,286,287,290],instruct:[3,4,7,11,55,57,62,80,86,102,243,246,249,250,266,269,273,287,288,289,290,292,296,299,300],insuffici:[20,173],insur:[91,105],int16_t:[84,106],int32_max:27,int32_t:[84,106,264,265],int64_t:[84,106],int8:135,integ:[98,206,213,230,232],integr:[12,22,185,194,230],intellig:187,intend:[24,29,36,182,183,194,241],inter:[185,194,246],interact:[2,8,136,138,202,244,249,260,268,275,299],interchang:206,interconnect:[9,138],interdepend:[135,232],interest:[7,14,18,90,99,187,229,248,256,259,264,302],interfac:[4,18,21,30,31,90,134,139,140,141,142,157,158,187,189,191,193,194,196,197,198,200,201,212,215,216,242,255,257,258,266,270,272,285,288,289,292,298],intermedi:[165,166,172],intern:[7,20,88,90,95,99,103,140,141,146,173,182,183,184,192,199,201,202,206,222,226,266,286],internet:[7,12,21,243,246,247,254,257,267,278,294,297],interoper:[138,139],interpret:[143,145,213,217],interrog:286,interrupt:[84,88,96,99,134,189,196,286],interrupt_prior:286,interv:[20,27,29,103,105,213,217,218,246,288,292],interval_max:27,interval_min:27,intervent:102,intial:226,intiat:99,introduc:[1,30,185,231,232],introduct:[251,302],introductori:294,intuit:134,invalid:[20,84,134,142,148,158,159,173,177,178,185,253,261,277],invers:[94,104],invert:104,invoc:[6,263],invok:[2,253,277,281,292],involv:[16,17,19,22,99,102,187,194,253,277],io_cap:27,ioctl:158,iot:21,iotiv:287,ipsp:21,ipv6:21,irk:[19,27],irq_prio:[141,142],isbuildcommand:12,ism:21,ismylaptop:[285,286],isn:[99,185,256],isol:[99,229],isshellcommand:12,issu:[1,6,30,55,66,95,104,134,138,158,179,185,194,243,269,270,271,273,274,282,285,286],ist:106,it_len:134,it_typ:134,ital:252,ite_chr:261,item:[1,99,135,186,217,265],iter:[134,160,161,162,167,170,185,218],itf:215,its:[7,10,11,18,19,20,55,61,86,88,90,94,95,99,102,103,105,134,136,141,146,164,174,177,179,180,185,193,194,212,229,230,231,232,233,238,242,247,248,251,252,255,256,259,261,262,263,264,265,274,279,285,290,296,302],itself:[26,61,90,91,105,134,140,144,146,186,202,207,218,232,242,253,269,277,285,286],iv_build_num:134,iv_major:134,iv_minor:134,iv_revis:134,ize:91,jan:106,javascript:55,jb_read_next:206,jb_read_prev:206,jb_readn:206,je_arg:206,je_encode_buf:206,je_wr_comma:206,je_writ:206,jira:10,jlink:[61,99,247,254,269,271,278,288,292,295],jlink_debug:61,jlink_dev:61,jlinkex:[269,271,274,286],jlinkgdbserv:[249,292,299],job:[1,34,35,37,38,39,40,41,42,43,44,45,46,47,48,49,50,51,52,53,54,57,58,59,62,86,95,99,221,261],join:[3,140,241,254,278,302],json:[7,12,34,37,51,55,61,208,209,210,211,242,243,248,253,277,285],json_array_t:206,json_attr_t:[206,211],json_buff:[206,211],json_buffer_read_next_byte_t:206,json_buffer_read_prev_byte_t:206,json_buffer_readn_t:206,json_decod:[211,253,277],json_encod:[205,206,207,208,209,210,253,277],json_encode_object_entri:[208,209,210],json_encode_object_finish:[207,210],json_encode_object_start:[207,208,209],json_enum_t:206,json_read:206,json_read_object:206,json_simple_decod:[253,277],json_simple_encod:[253,277],json_typ:206,json_valu:[206,207,208,209,210],json_value_int:[206,209],json_value_str:206,json_value_stringn:206,json_write_func_t:206,jtag:[4,38,42,47,254,266,269,270,272,278,292,298],jul:80,jump0:67,jump:[134,229],jumper:[8,242,272,285,286,298],just:[1,7,8,20,22,23,62,85,99,100,105,134,141,142,157,172,177,229,242,260,261,264,265,266,268,274,281,282,285,286],jv_len:206,jv_pad1:206,jv_type:206,jv_val:206,k30:[284,285],k64f:53,keep:[9,22,24,95,134,136,140,146,185,214,221,222,226,229,242,248,251,253,277,286],keg:[60,83],kei:[8,19,20,21,31,37,46,57,80,99,134,135,185,205,206,207,209,232,261,274,278,285,288],kept:[86,134,146],kernel:[1,7,9,51,55,61,99,136,140,187,196,201,218,229,232,246,256,257,285,286,287,288,290,292],kernel_o:229,keyboard:[12,22,136],keyboarddisplai:27,keyboardonli:27,keychain:[57,80],keystor:27,keyword:[1,61,100,136,277,279,285,286],khz:[197,266,270],kick:[103,264,265],kilobyt:102,kind:[31,140,249,285,286,299],kit:[8,47,61,242,247,248,249,250,267,269,286,299,300,302],klibc:107,know:[1,8,12,30,61,136,213,217,230,231,251,254,261,262,264,265,267,268,278,285,286,297,302],known:[21,55,106,166,167,185,251,259],l13:269,l2cap:21,lab:32,label:[8,99,272,286],lack:[146,157,229],lag:263,languag:[11,12,55,102,143,285,286],laptop:[3,8,242,243,246,248,257,274,285,286],larg:[20,24,31,90,105,229,230,251],large_system_test:[253,277],large_unlink_test:[253,277],large_write_test:[253,277],larger:[10,31,90,93,233],largest:[93,252],las_app_port:274,las_app_tx:274,las_join:274,las_link_chk:274,las_rd_app_eui:274,las_rd_app_kei:274,las_rd_dev_eui:274,las_rd_mib:274,las_wr_app_eui:274,las_wr_app_kei:274,las_wr_dev_eui:274,las_wr_mib:274,last:[20,26,72,77,103,134,154,185,208,213,221,226,232,254,259,263,264,265,266,274,278,286,288,290,292],last_checkin:[77,295,298],last_n_off:154,last_op:194,last_read_tim:215,latenc:27,later:[7,8,72,85,90,134,238,248,249,250,253,256,262,266,274,277,286,292,299,300],latest:[1,2,4,7,10,11,49,52,55,56,60,79,83,135,242,254,266,278,279,280,285,286],latex:[179,185],latter:[20,90,138,179],launch:12,launchpad:4,law:[249,250,266,285,286,292,299,300],layer:[9,20,21,90,101,102,140,158,168,171,179,186,215,216,232,246,258,286,302],layout:[102,134,180,298],lc_f:214,lc_pull_up_disc:214,lc_rate:214,lc_s_mask:214,lcheck:285,ld4:270,ldebug:231,ldflag:50,ldr:272,le_elem_off:151,lead:[90,95,262,286],leak:[166,167],learn:[7,26,61,242,248,267,294],least:[22,90,103,134,185,243,268,274,286,302],leav:[90,141,154,229],led1:[246,271],led2:246,led3:246,led:[1,7,61,99,102,105,140,187,193,243,246,251,254,257,266,267,268,269,270,271,272,273,278,285,286,288,295,298,302],led_blink_pin:[99,105,248,251,268],led_blink_pin_1:248,led_blink_pin_2:248,led_blink_pin_3:248,led_blink_pin_4:248,led_blink_pin_5:248,led_blink_pin_6:248,led_blink_pin_7:248,led_blink_pin_8:248,led_pin:248,left:[84,91,105,151,205,229,272,284,292,302],legaci:[30,157,232,251],len:[90,141,146,147,168,169,176,177,178,194,206,211,261,274,285],length:[20,21,27,90,99,134,136,146,162,163,182,185,205,261,274],less:[95,107,134,185,263,264,265],lesser:185,lesson:[251,302],let:[4,8,55,90,93,99,212,229,230,242,251,253,256,258,259,260,261,262,263,264,265,268,272,277,279,280,284,285,286,292],level:[1,2,9,14,18,20,23,27,29,30,31,32,34,35,37,38,39,40,41,42,43,44,45,46,47,48,49,50,51,52,53,54,55,57,58,59,61,62,64,65,66,67,68,69,70,71,72,73,74,75,76,77,80,81,82,89,94,99,137,140,141,158,179,180,187,215,231,232,241,253,254,260,261,264,265,266,270,274,277,278,280,284,285,286],level_list:72,leverag:[138,140,255,286],lflag:[1,50,61],lib:[1,4,45,53,55,82,107,136,158,186,231,232,285,286],libc6:6,libc:[7,99,107],libc_baselibc:[229,272],libftdi1:4,libftdi:4,libg:48,libgcc:[48,229],libhidapi:4,librari:[1,4,48,50,55,58,81,88,90,99,100,102,107,134,136,140,158,166,186,187,202,229,230,238,253,256,277,279,280,285,286,287],libusb:4,libusb_error_access:270,libusb_open:270,licens:[4,7,11,55,61,107,140,249,250,254,256,266,270,272,273,278,279,285,286,292,299,300],lieu:66,life:[24,264],light:[9,31,187,213,242,246,248,267,270,271,272,273,287,288,295,298],lightblu:[260,284,286],lightweight:157,like:[2,3,5,8,12,31,55,58,59,62,81,82,90,95,99,102,103,104,107,134,136,140,146,187,194,230,242,248,249,250,253,256,266,270,272,277,279,285,286,287,289,290,292,294,298,299,300],likewis:[62,185],limit:[3,20,27,29,105,107,141,157,222,226,229,243,249,259,264,285,286,299],limt:230,line:[2,6,7,10,12,36,38,39,47,62,99,107,136,193,230,236,242,248,249,257,263,268,270,271,279,281,285,286,287,288,292,299],linear:185,linearacc:288,lines_queu:136,link:[2,3,7,20,21,22,27,34,38,42,60,61,81,83,86,88,90,185,199,221,229,232,238,241,242,249,250,254,256,257,260,265,266,268,269,270,271,272,273,274,278,285,286,288,292,295,296,298,299,300,302],linkag:[85,88],linker:[1,61,100,107,229,256,272],linkerscript:[61,99],linux:[5,7,9,12,56,66,78,79,141,247,254,257,266,268,269,270,272,273,278,288,295,296,297,298],liquid:286,lis2dh12:[214,292],lis2dh12_0:[214,292],lis2dh12_cfg:214,lis2dh12_config:214,lis2dh12_data_rate_hn_1344hz_l_5376hz:214,lis2dh12_fs_2g:214,lis2dh12_init:214,lis2dh12_onb:292,list:[3,6,7,8,12,22,27,29,34,35,48,50,51,53,57,59,61,66,71,72,73,75,76,77,78,80,86,88,90,91,94,99,100,101,104,105,134,136,137,140,142,185,186,199,212,221,230,232,233,236,241,242,247,248,256,259,262,263,266,267,268,269,270,271,272,273,274,279,280,285,286,290,295,296,298,302],listen:[2,14,30,31,66,92,213,218,229,259],listener_cb:292,lit:[243,248,251,257],littl:[6,20,23,90,134,242,248,256,263,274,280,285],live:[140,242,254,262,263,266,278,279,280],lma:272,lmp:20,load:[2,4,5,7,12,34,39,43,47,55,57,58,59,61,99,134,135,229,242,246,247,248,249,250,251,260,267,268,274,280,284,285,286,299,300],load_arduino_blinki:12,load_arduino_boot:12,loader:[10,43,50,99,134,136,254,266,269,270,271,273,278,288,295,296,298],loc:[147,151,156],local:[1,4,6,7,10,11,20,27,28,36,40,49,55,58,60,71,81,83,100,105,106,252,254,259,266,278,290],localhost:[66,249,292,299],locat:[1,8,11,19,31,61,99,134,146,151,185,194,238,251,254,263,268,272,278,279,285,288,295,296,298],lock:[9,89,95,104,146,213,218,246],log:[1,7,10,34,35,37,38,39,40,41,42,43,44,45,46,47,48,49,50,51,52,53,54,57,58,59,62,64,65,66,67,68,69,70,71,73,74,75,76,77,78,80,81,82,134,137,138,156,165,172,186,187,221,229,231,232,242,243,244,249,256,266,269,270,272,273,275,285,286,290,292,296,299],log_cbm_handl:212,log_cbmem_handl:212,log_cli:[221,244,275],log_console_handl:[212,215],log_debug:212,log_error:215,log_fcb:232,log_fcb_handl:212,log_handl:212,log_info:215,log_init:232,log_level:[50,212,232,244,247,275],log_level_debug:212,log_level_error:212,log_module_bno055:215,log_module_default:212,log_nam:72,log_newmgr:231,log_newtmgr:[50,231,232,243],log_nmgr_register_group:232,log_regist:[212,215],log_shel:242,log_syslevel:[212,215],logic:[1,21,23,29,134,180,274,285],login:281,loglevel:[1,34,35,37,38,39,40,41,42,43,44,45,46,47,48,49,50,51,52,53,54,57,58,59,62,64,65,66,67,68,69,70,71,72,73,74,75,76,77,80,81,82,285],logxi:81,long_filename_test:[253,277],longer:[3,8,11,21,24,91,217,231,257,285,287],longjmp:240,longrange_interv:27,longrange_pass:27,longrange_window:27,look:[8,10,24,55,61,99,101,105,107,134,136,137,194,206,211,229,230,242,248,251,252,253,259,261,262,263,277,280,282,284,285,286,290,292,302],lookup:[218,227,261,292],loop:[85,88,95,105,160,161,162,167,170,232,243,251,256,268,284,285,286],lora:274,lora_app_shel:274,lora_app_shell_telee02:274,lora_app_shell_telee0:274,lora_mac_timer_num:274,lose:26,loss:[26,29],lost:[103,185],lost_found_test:[253,277],lot:[7,229,231,253,259,277,286],low:[9,20,21,22,31,84,90,99,104,141,158,187,197,215,251,254,261,264,265,266,267,270,278,302],lower:[20,84,87,94,95,104,105,231,232,247,251,258,268,272],lowest:[73,86,91,185,232,251],lowpow:288,lru:185,lrwxr:[4,81],lsb:194,lst:[34,55,61],ltbase:232,ltd:27,ltk:27,ltk_sc:27,ltrequir:232,lua:[143,144,145],lua_cmd:145,luckili:285,m32:6,m4g:288,mac:[3,5,7,9,12,20,55,56,78,79,242,247,248,254,257,260,266,268,269,270,272,273,274,278,284,286,288,295,296,297,298],machin:[2,3,7,8,100,257,302],maco:[4,66],macro:[20,90,91,99,103,206,213,215,230,232,238,251,253,263,277,286],made:[2,10,11,20,55,71,84,105,134,194,251,252,274,286],mag:288,mag_rev:288,maggyro:288,magic:[61,134,146,185],magnet:[213,288],magnetomet:215,mai:[2,4,6,7,8,12,22,27,29,30,31,51,53,57,58,62,80,81,82,88,90,91,93,95,99,102,107,134,136,138,140,167,185,187,193,194,212,213,214,215,217,218,229,230,231,232,233,236,238,243,249,251,254,256,257,266,268,269,270,271,272,273,274,278,279,285,286,288,292,295,298,299],mail:[3,10,140,241,242,248,256,267,286,302],main:[7,12,26,31,57,61,77,80,88,90,95,101,105,134,136,144,182,183,204,213,218,221,223,228,232,237,239,243,246,248,253,256,259,264,265,266,269,270,271,272,273,277,284,285,286,288,295,296,298],mainli:229,maintain:[4,49,86,134,140,185,213,218,232,253,277,279,280],mainten:[138,230],major:[55,61,102,204,251,265,279,280],major_num:[279,280],make:[1,2,3,7,8,9,19,20,21,24,30,31,33,55,57,63,71,86,90,91,99,134,140,146,147,179,185,187,205,212,229,230,242,247,248,251,253,255,256,257,259,261,262,264,265,266,268,272,274,277,279,284,285,286,287,292,302],makerbeacon:243,malloc:[89,91,99,107,251,286],man:[6,27,107],manag:[6,8,16,17,21,27,31,39,45,57,58,59,61,64,66,68,71,72,73,76,77,80,81,82,88,95,99,100,102,134,136,140,187,203,206,213,215,216,217,229,232,244,247,254,268,269,275,278,280,288,292,295,297,298,302],mandatori:[20,99,233,263,264,265],mani:[20,31,55,61,90,99,101,134,146,154,166,167,187,188,199,261,266,279],manifest:[34,37,43,55,61,242,243,248,285],manipul:[1,39,45,90],manner:[27,29,93,95,134,187],manual:[21,25,60,83,95,105,107,179,229,236,242,249,250,266,272,292,298,299,300],manufactur:[19,27,29,39,43,57,58,59,66,229,254,259,266,278],many_children_test:[253,277],map:[2,3,8,20,27,28,61,102,140,141,166,187,192,193,206,229,231,232,249,254,261,268,278,279,280,288,295,298,299],mar:[106,269,271,274,286,292],march:68,mark:[27,28,71,99,272],marker:99,market:[31,271],mask:[27,213,215,217,218,290,292],mass:[257,270],mass_eras:[269,270],master:[1,7,11,27,56,57,59,60,79,80,82,83,140,187,190,194,197,252,254,266,278,279,280],match:[2,7,20,99,100,102,134,217,218,229,254,266,270,278,279,280],matter:10,max:[162,205,206],max_cbmem_buf:212,max_conn_event_len:27,max_ev:27,max_len:[162,168],maxim:9,maximum:[21,27,29,90,134,136,179,181,185,205,221,222,226,249,253,277,299],mayb:[249,250,299,300],mb_crc:285,mb_crc_check:285,mb_crc_tbl:285,mbed:[269,273],mbedtl:[7,254,266,269,271,273,278,295,296,298],mblehciproj:257,mblen:90,mbuf:[93,95,206,289],mbuf_buf_s:90,mbuf_memblock_overhead:90,mbuf_memblock_s:90,mbuf_mempool_s:90,mbuf_num_mbuf:90,mbuf_payload_s:90,mbuf_pkthdr_overhead:90,mbuf_pool:90,mbuf_usage_example1:90,mbuf_usage_example2:90,mcu:[7,9,53,100,103,140,141,187,193,196,198,202,242,248,251,254,266,269,278,292],mcu_gpio_porta:141,mcu_sim_parse_arg:[268,292],mdw:272,mean:[2,12,20,90,93,98,103,106,134,141,181,197,208,210,232,240,263,270,280,285,286],meaning:144,meant:[1,103,135],measur:[9,251,274],mechan:[1,22,95,229,232,246,279,281,285,286],medic:[21,55],medium:173,meet:[214,247,257,266,267,269,270,271,272,273,288,290,291,292,294,295,296,297,298],mem:[7,232],member:[84,136,259,261],memcpi:261,memori:[9,20,48,73,88,89,90,95,99,102,103,107,134,138,140,141,157,173,179,180,184,185,187,189,191,194,222,226,231,243,244,246,249,251,261,272,274,275,296,299],mempool:[64,80,81,82,221,285],memset:[214,259,262,265,286],mention:[12,185,213,286],menu:[12,59,270,272,298],merchant:4,merci:91,merg:252,mesh:32,messag:[2,4,22,31,42,57,58,59,75,136,138,139,172,221,224,225,233,246,254,266,270,274,278,285],messi:286,messsag:62,met:[20,243,246,254,278],meta:[8,278,288],metadata:[43,134,173],meter:21,method:[25,90,105,139,179,190,193,197,212,221,230,261,279],mfg:[7,39,57,58,59,70,232],mfg_data:29,mfg_init:232,mgmt:[7,136,138,203,221,231,232,243,285,286],mgmt_evq_set:243,mgmt_group_id_config:137,mgmt_group_id_crash:137,mgmt_group_id_default:137,mgmt_group_id_imag:137,mgmt_group_id_log:137,mgmt_group_id_runtest:137,mgmt_group_id_stat:137,mgmt_imgmgr:229,mgmt_newtmgr_nmgr_o:229,mgutz:81,mhz:[21,24],mib:[55,81,274],mic:20,micro:[55,247,249,250,251,254,266,267,269,271,272,274,278,286,288,294,295,297,298,299,300],microcontrol:[9,107,134,272,298],microsecond:[24,84],microsoft:12,mid:[14,134,270],middl:[27,134,185,286],might:[1,2,18,20,61,99,102,136,140,185,187,194,215,229,231,249,250,256,258,259,264,265,266,270,279,280,282,292,299,300],migrat:[185,232],milisecond:27,millisecond:[27,106,274],millivolt:286,min:[72,73,134,278,296],min_conn_event_len:27,mind:[103,256],mingw32:59,mingw64:59,mingw:[4,7,8,12,56,82,254,268,278,288,295,298],mini:270,minicom:[8,254,268,278,285,288],minim:[99,140,157,158,179,185,215,256],minimum:[27,29,72,90,134,185,256],minor:[204,265,279,280],minor_num:[279,280],minut:[81,253,264,277],mip:[7,61],mirror:[1,10,11,279,285,286],misc:288,mislead:6,mismatch:20,miso:197,miso_pin:[141,142],miss:[20,57,99,231,242,248,256,267,286],misspel:231,mitm:27,mk64f12:[140,187],mkdir:[11,43,80,82,99,242,254,266,269,270,271,272,273,274,278,279,285,286],mkdir_test:[253,277],mkdoc:252,mkr1000:276,mkr1000_boot:[254,278],mkr1000_wifi:[254,278],mlme:274,mman:57,mmc0:[142,158],mmc:157,mmc_addr_error:142,mmc_card_error:142,mmc_crc_error:142,mmc_device_error:142,mmc_erase_error:142,mmc_init:142,mmc_invalid_command:142,mmc_ok:142,mmc_op:[142,158],mmc_param_error:142,mmc_read_error:142,mmc_response_error:142,mmc_timeout:142,mmc_voltage_error:142,mmc_write_error:142,mn_socket:7,mobil:31,mod:[30,260],modbu:285,mode:[9,20,22,27,29,140,164,166,173,174,176,187,197,200,215,229,253,259,266,270,272,277,288],model:[21,22,32,88,202,269],modern:[8,157],modif:[11,242,253,277,287],modifi:[6,62,99,139,199,248,251,285,286,291,294],modul:[72,84,87,91,95,107,138,143,212,222,226,228,253,268,274,298],module_list:72,module_nam:[226,228],modulo:106,moment:[141,194,202,261,280],mon:[266,269,270],monitor:[92,136,138,146,219,230,272,287,294,302],monolith:263,month:[253,277],more:[1,4,7,9,10,12,20,21,22,29,30,34,35,39,43,51,53,57,58,59,61,62,64,80,81,82,86,88,90,95,99,104,105,106,107,134,135,140,147,151,158,169,170,185,206,212,213,214,215,216,221,229,232,233,247,248,249,251,253,254,256,259,263,264,265,266,268,269,274,277,278,280,284,285,286,288,292,295,298,299,302],mosi:197,mosi_pin:[141,142],most:[1,8,14,19,21,23,24,25,61,90,99,100,105,107,134,185,190,229,231,251,253,259,277,284,285,286,288,290,292],mostli:[6,9,229,264,265],motor:9,mou:252,mount:[171,286],mous:[140,187],move:[8,45,57,58,59,81,84,95,134,172,229,268,272,286,287,289,292],mp_block_:91,mp_block_siz:91,mp_list:91,mp_membuf_:91,mp_membuf_addr:91,mp_min_fr:91,mp_min_fre:91,mp_num_blo:91,mp_num_block:91,mp_num_fr:91,mp_num_fre:91,mpool:[226,274],mpstat:[64,78,80,81,82,137,139,243,296],mq_ev:92,mq_head:92,msb:194,msdo:99,msec:27,msg:236,msg_data:27,msp:[266,272],msy:59,msys2:56,msys2_path_typ:59,msys64:59,msys_1:[73,296],msys_1_block_count:[287,289],msys_1_block_s:[287,289],mtd:141,mtu:[10,20,27,28,260],mu_head:94,mu_level:94,mu_own:94,mu_prio:94,much:[90,99,104,107,152,185,285],multi:[1,9,50,62,102,105,194],multilib:[6,7,57],multipl:[4,23,27,29,34,35,50,51,55,85,94,95,103,107,135,138,140,187,218,232,259,263,264,279],multiplex:21,multiplexor:102,multipli:[91,251],multitask:[95,251],must:[1,2,4,5,7,8,9,11,12,14,22,24,25,33,37,41,46,53,55,57,59,61,63,66,68,71,80,84,87,88,90,91,95,96,99,102,103,105,134,135,136,142,146,154,158,165,166,168,172,179,180,181,182,184,185,186,197,199,204,205,206,212,213,214,215,217,218,219,221,222,223,226,230,231,232,239,242,243,247,249,251,254,256,259,261,268,271,272,274,278,279,280,285,286,288,289,290,291,292,295,298,299],mutex:[89,95,104,105],mutual:94,my_at45db_dev:141,my_blinki:50,my_blinky_sim:[7,34,35,43,55,61,256,257,269,270,285],my_blocking_enc_proc:20,my_callout:246,my_conf:135,my_config_nam:232,my_driv:[285,286],my_ev_cb:246,my_eventq:243,my_gpio_irq:246,my_interrupt_ev_cb:246,my_memory_buff:91,my_new_target:50,my_newt_target:50,my_packag:212,my_package_log:212,my_pool:91,my_proj1:256,my_proj:256,my_project:[1,254,266,278,279,286],my_protocol_head:90,my_protocol_typ:90,my_result_mv:286,my_sensor:292,my_sensor_devic:292,my_sensor_poll_tim:292,my_stack_s:105,my_stat:230,my_stat_sect:230,my_target1:62,my_task:105,my_task_evq:92,my_task_func:105,my_task_handl:92,my_task_pri:105,my_task_prio:105,my_task_rx_data_func:92,my_task_stack:105,my_timer_ev_cb:246,my_timer_interrupt_eventq:246,my_timer_interrupt_task:246,my_timer_interrupt_task_prio:246,my_timer_interrupt_task_stack:246,my_timer_interrupt_task_stack_sz:246,my_timer_interrupt_task_str:246,my_uart:200,myadc:286,myapp1:[249,299],myapp:230,myapp_cmd:227,myapp_cmd_handl:227,myapp_console_buf:136,myapp_console_ev:136,myapp_init:136,myapp_process_input:136,myapp_shell_init:227,mybl:[34,35,46,50,66,73,76,77,243],myble2:[37,38,257],myblehostd:66,mybleprph:[66,247],mybletyp:66,myboard:[45,99],myboard_debug:99,myboard_download:99,mycmd:228,myconn:243,mycor:71,mydata:90,mydata_length:90,mylora:274,mymcu:101,mymfg:70,mymodul:103,mymodule_has_buff:103,mymodule_perform_sanity_check:103,mymodule_register_sanity_check:103,mynewt:[1,3,4,5,6,11,13,20,21,25,30,32,37,38,39,43,44,50,51,53,55,56,57,59,60,61,62,71,78,79,80,82,83,85,87,88,89,90,91,92,93,94,103,104,105,106,107,134,135,138,139,140,157,158,179,186,187,189,190,193,197,200,212,215,221,223,229,230,231,232,238,241,242,243,244,246,247,249,250,251,253,254,255,257,258,260,264,265,266,267,268,269,270,271,272,273,274,275,277,278,280,284,285,286,288,291,292,295,296,297,298,299,300,302],mynewt_0_8_0_b2_tag:[279,280],mynewt_0_8_0_tag:279,mynewt_0_9_0_tag:279,mynewt_1_0_0_b1_tag:279,mynewt_1_0_0_b2_tag:279,mynewt_1_0_0_rc1_tag:279,mynewt_1_0_0_tag:279,mynewt_1_3_0_tag:[57,59,80,82],mynewt_arduino_zero:[254,266,278,279],mynewt_nord:286,mynewt_stm32f3:242,mynewt_v:[136,221,226,230,232,253,277,286],mynewt_val_:232,mynewt_val_log_level:232,mynewt_val_log_newtmgr:232,mynewt_val_msys_1_block_count:232,mynewt_val_msys_1_block_s:232,mynewt_val_my_config_nam:232,mynewtl:287,mynewtsan:75,myperiph:[247,260],mypool:91,myproj2:229,myproj:[2,7,12,99,242,247,248,250,266,268,269,270,271,272,273,279,285,287,288,292,300],myriad:9,myseri:[73,76,77],myserial01:66,myserial02:66,myserial03:66,mytask:251,mytask_handl:251,mytask_prio:251,mytask_stack:251,mytask_stack_s:251,myudp5683:66,myvar:65,n_sampl:288,nad_flash_id:180,nad_length:180,nad_offset:180,name1:50,name2:50,name:[1,2,4,7,8,10,11,12,20,21,27,29,34,35,37,38,42,43,44,45,47,48,50,51,53,55,57,58,59,61,62,64,65,66,67,68,69,70,71,72,73,74,75,76,77,80,81,82,91,99,100,101,103,106,107,135,136,140,158,160,161,162,165,166,167,170,186,187,193,205,206,207,209,211,212,213,214,215,216,218,222,226,227,228,229,231,234,235,237,242,243,246,249,251,253,254,256,259,261,263,264,265,266,268,269,270,271,272,273,277,278,279,280,281,285,286,287,288,289,292,295,296,298,299],name_is_complet:259,name_len:[160,161,162,167,170,259],namespac:[85,88,90,91,92,93,94,103,104,135,221,264],nano2:[43,53,99,273],nano2_debug:[99,273],nano:[267,302],nanosecond:84,nativ:[2,3,7,12,43,50,53,55,59,61,66,231,232,242,246,257,269,270,278,285,286,296,302],natur:[99,185],navig:[10,302],nb_data_len:185,nb_hash_entri:185,nb_inode_entri:185,nb_prev:185,nb_seq:185,nc_num_block:181,nc_num_cache_block:181,nc_num_cache_inod:181,nc_num_fil:181,nc_num_inod:181,ncb_block:185,ncb_file_offset:185,ncb_link:185,ncheck:285,nci_block_list:185,nci_file_s:185,nci_inod:185,nci_link:185,nda_gc_seq:185,nda_id:185,nda_length:185,nda_mag:185,nda_ver:185,ndb_crc16:185,ndb_data_len:185,ndb_id:185,ndb_inode_id:185,ndb_magic:185,ndb_prev_id:185,ndb_seq:185,ndi_crc16:185,ndi_filename_len:185,ndi_id:185,ndi_mag:185,ndi_parent_id:185,ndi_seq:185,nding:263,ndof:288,ndof_fmc_off:288,nearest:269,neatli:259,necessari:[6,24,39,47,57,58,59,134,158,185,240,242,253,256,261,266,274,277,286],need:[4,5,6,7,8,9,10,11,12,14,23,24,32,43,50,52,55,57,58,59,60,61,64,66,80,81,83,84,85,89,90,91,94,95,99,101,102,103,104,105,134,136,141,146,147,148,158,185,201,212,213,215,216,217,218,221,227,229,230,231,232,236,243,246,247,251,253,254,256,257,259,261,262,263,264,265,266,268,269,270,271,272,273,277,278,280,281,284,287,289,292,295,296,298],neg:[106,185,263],nest:[94,165],net:[4,7,24,51,219,232,254,256,257,261,263,278,285,286,287,289,291],net_nimble_control:229,net_nimble_host:229,network:[1,9,23,27,31,32,55,90,92,95,229,251,254,274,278],never:[19,95,103,105,172,185,232,251,256,261],new_bletini:45,new_slinki:45,newer:6,newest:[146,231,251],newli:[1,10,19,43,134,166,257,264,265,279],newlib:107,newlin:136,newt:[1,3,5,6,7,13,32,56,61,62,73,76,77,80,81,82,83,91,95,99,100,102,140,229,230,231,232,238,242,244,245,246,247,248,249,250,251,253,254,255,256,257,260,264,265,266,267,268,269,270,271,272,273,274,275,277,278,279,280,281,282,285,286,287,288,289,290,292,294,295,296,297,298,299,300,302],newt_1:[57,60],newt_1_1_0_windows_amd64:60,newt_1_3_0_windows_amd64:59,newt_group:2,newt_host:2,newt_us:2,newtgmr:[81,82,83],newtmgr:[1,7,9,10,13,57,58,59,63,64,78,79,136,137,139,202,212,224,225,229,231,232,246,285,286,297,302],newtmgr_1:[80,83],newtmgr_1_1_0_windows_amd64:83,newtmgr_1_3_0_windows_amd64:82,newtmgr_shel:221,newtron:[158,186,231,232],newtvm:11,next:[7,8,24,30,71,77,82,84,86,90,91,134,136,138,146,151,160,161,162,167,170,185,202,206,213,217,218,229,232,240,247,248,251,252,256,259,263,264,265,266,269,272,280,284,285,286],next_checkin:[77,295,298],next_t:84,nff:[7,107,141,158,180,181,182,183,184,186,195,231,232,238,253,277],nffs_area_desc:[179,182,183,233],nffs_area_mag:185,nffs_area_max:[182,183],nffs_block:185,nffs_block_cache_entri:185,nffs_block_cache_list:185,nffs_block_mag:185,nffs_cache_block:185,nffs_cache_block_list:185,nffs_cache_inod:185,nffs_close:186,nffs_closedir:186,nffs_detect:[183,185],nffs_detect_fail:[158,179],nffs_dirent_is_dir:186,nffs_dirent_nam:186,nffs_disk_area:185,nffs_disk_block:185,nffs_disk_inod:185,nffs_file_len:186,nffs_flash:195,nffs_flash_area:[231,232],nffs_format:[182,185,233],nffs_getpo:186,nffs_hash_entri:185,nffs_id_non:185,nffs_init:[181,182,183,186],nffs_inod:185,nffs_inode_entri:185,nffs_inode_list:185,nffs_inode_mag:185,nffs_intern:179,nffs_mkdir:186,nffs_op:186,nffs_open:186,nffs_opendir:186,nffs_read:186,nffs_readdir:186,nffs_renam:186,nffs_seek:186,nffs_short_filename_len:185,nffs_test:[253,277],nffs_test_debug:[253,277],nffs_test_priv:[253,277],nffs_test_system_01:[253,277],nffs_test_unlink:233,nffs_test_util:[253,277],nffs_unlink:186,nffs_write:186,nhe_flash_loc:185,nhe_id:185,nhe_next:185,ni_filenam:185,ni_filename_len:185,ni_inode_entri:185,ni_par:185,ni_seq:185,nice:[230,284],nie_child_list:185,nie_hash_entri:185,nie_last_block_entri:185,nie_refcnt:185,nie_sibling_next:185,nil:67,nim:263,nimbl:[7,23,24,26,29,66,88,232,243,247,255,258,259,260,261,262,263,285,286,287,289],njb:[207,208,209,210,211],njb_buf:211,njb_enc:209,nlip:224,nmgr:139,nmgr_def_taskstat_read:209,nmgr_err_eok:209,nmgr_jbuf:[207,208,209,210,211],nmgr_o:137,nmgr_shell:[136,232,243],nmgr_shell_in:224,nmgr_shell_out:225,nmgr_shell_pkg_init:232,nmgr_task_init:224,nmgr_transport:225,nmgr_uart:243,nmgr_urart_spe:243,nmxact:11,no_of_sampl:288,no_rsp:28,no_wl:[27,30],no_wl_inita:27,node:[21,32,55,160,161,162,167,170,185],nodefault:[206,211],nodup:27,nogdb:[38,47],noinputnooutput:27,non:[7,18,19,21,24,27,31,32,90,150,154,156,185,197,222,224,225,226,229,232,264,265,274,279,292],none:[4,7,8,12,20,27,30,82,96,97,98,99,107,134,185,223,227,228,229,233,236,242,249,250,266,270,274,286,292,299,300],nonexist:[166,185],nonsens:[253,277],nonzero:[147,148,149,151,152,155,156,234,235,237,239,240,253,262,277],nor:22,nordic:[23,99,140,187,192,196,198,246,247,269,271,285,286,288,292,297,302],nordicsemi:[269,271,274,286,292],normal:[2,104,185,236,238,284,288],notat:[55,272],note:[1,2,4,6,7,10,11,12,21,22,23,24,29,32,43,47,50,57,58,59,60,61,66,68,71,80,81,82,83,84,88,90,91,93,94,95,99,100,105,134,136,142,179,194,199,202,213,214,215,216,218,221,222,226,229,231,232,242,243,244,247,249,251,252,254,256,257,259,261,263,264,265,266,268,269,270,271,272,273,274,275,278,279,280,281,285,287,288,289,290,292,294,295,296,298,299,302],noth:[11,185,233,264,265,285,286],notic:[7,11,55,61,95,99,186,229,251,256,280,284,285,286],notif:[10,27,28,88,136,217,258,284],notifi:[10,28,217,262,263],notnul:232,nov:8,now:[2,8,9,59,84,90,91,94,99,104,105,134,157,159,163,166,169,172,174,176,185,193,229,242,243,247,248,249,250,251,253,256,258,259,260,262,263,264,265,266,269,274,277,279,284,285,286,288,292,296,299,300],nreset:266,nrf51:[24,53,99,140,187,244,275],nrf51dk:[53,229],nrf51xxx:196,nrf52840pdk:32,nrf52:[4,24,61,99,140,187,192,198,214,246,247,249,250,257,267,268,269,274,285,287,289,292,297,299,300,302],nrf52_adc_dev_init:286,nrf52_bleprph_oic_bno055:287,nrf52_blinki:[249,268,271,273,299],nrf52_bno055_oic_test:[287,289],nrf52_bno055_test:[288,290],nrf52_boot:[243,257,271,286,287,288,289,295],nrf52_hal:99,nrf52_slinki:295,nrf52_thingi:214,nrf52dk:[37,38,53,61,62,99,232,246,256,257,260,268,271,286,287,288,289,295],nrf52dk_debug:[61,99,268],nrf52dk_download:99,nrf52k_flash_dev:[99,192],nrf52pdk:[257,271],nrf52serial:295,nrf52xxx:[48,99,198,269,292],nrf5x:24,nrf:[25,286],nrf_drv_saadc:286,nrf_drv_saadc_config_t:286,nrf_drv_saadc_default_channel_config_s:286,nrf_drv_saadc_default_config:286,nrf_saadc_channel_config_t:286,nrf_saadc_gain1_6:286,nrf_saadc_input_ain1:286,nrf_saadc_reference_intern:286,nrf_saadc_typ:286,nrpa:[19,264,265],nsampl:288,nsec:84,nth:185,ntick:84,ntoh:90,ntohl:90,ntrst:266,nucleo:53,nul:185,num_block:91,number:[1,8,9,10,22,27,34,35,37,38,39,40,41,42,43,44,45,46,47,48,49,50,51,52,53,54,57,58,59,60,61,62,64,65,66,67,68,69,70,71,72,73,74,75,76,77,80,81,82,83,84,87,90,91,93,94,95,99,104,106,107,134,135,145,146,147,157,163,169,174,176,177,178,179,180,181,185,193,194,202,204,205,206,213,221,222,226,230,231,232,236,243,246,247,249,251,254,257,263,264,265,266,268,272,274,278,279,280,284,285,286,288,289,295,298,299],numer:[20,22,86,99,134],nvm:266,nxp:[140,187],objcopi:6,objdump:6,object:[4,11,48,55,61,81,84,95,99,102,105,138,172,206,208,209,210,215,217,218,253,262,277,288,291],objsiz:[6,48,229],observ:[14,27,219,257,291],obtain:[27,90,94,104,105,185,279,285,286],obvious:53,oc_add_devic:287,oc_add_resourc:287,oc_app_resourc:[287,289],oc_get:287,oc_if_rw:287,oc_init_platform:287,oc_main_init:[219,287],oc_new_resourc:287,oc_put:287,oc_resource_bind_resource_interfac:287,oc_resource_bind_resource_typ:287,oc_resource_set_default_interfac:287,oc_resource_set_discover:287,oc_resource_set_periodic_observ:287,oc_resource_set_request_handl:287,oc_serv:[219,243,287,289,291],oc_transport_gatt:243,oc_transport_ip:243,oc_transport_seri:243,occasion:90,occur:[26,27,90,94,106,231,261,262,264,265],occurr:232,ocf:138,ocf_sampl:[7,61],ocimgr:137,ock:218,oct:285,octet:[27,29,31,134],od_init:140,od_nam:215,off:[2,20,21,31,32,102,103,105,136,140,146,187,194,211,213,215,216,220,243,246,247,248,256,257,264,265,268,272,287,289,290,291,292,294,302],off_attr:211,offer:[1,21,138,140,157,191,286],offset:[20,28,71,99,106,134,146,154,158,164,168,173,174,176,177,178,180,185,206,229,231,232,288],often:[9,55,99,185,194,197],ohm:286,oic:[7,51,66,138,216,217,292,302],oic_bhd:66,oic_bl:66,oic_seri:66,oic_udp:66,oic_udpconnstr:66,oicmgr:[7,66,137,138,139],old:[45,146],older:[10,59,82,270],oldest:[146,151,155,231],olimex:[267,285,297,302],olimex_blinki:272,olimex_stm32:[53,272,298],om_data:90,om_databuf:90,om_flag:90,om_len:90,om_next:90,om_omp:90,om_pkthdr_:90,om_pkthdr_len:90,omgr:139,omi_block_s:91,omi_min_fre:91,omi_nam:91,omi_num_block:91,omi_num_fre:91,omit:[47,231],omp_databuf:90,omp_databuf_len:90,omp_flag:90,omp_len:90,omp_mbuf_c:90,omp_mbuf_count:90,omp_next:90,omp_pool:90,on_reset:26,on_sync:26,onboard:[215,216,249,250,290,294,299,300,302],onc:[19,29,55,57,61,80,84,85,90,91,94,95,97,105,134,149,187,240,242,243,247,248,259,264,267,268,274,279,285,286],one:[1,4,7,8,10,11,12,19,20,21,22,23,27,29,30,31,34,35,39,43,45,50,51,53,57,58,59,61,67,86,88,90,92,93,94,95,99,102,104,105,134,135,136,142,143,146,158,171,172,179,180,182,183,185,194,202,212,213,217,218,227,229,230,231,232,248,251,252,253,254,256,257,263,264,265,266,267,268,269,270,271,272,273,274,277,278,279,280,281,284,285,286,288,294,295,298,302],ones:[14,90,104,140,187,212,257,302],ongo:27,onli:[1,2,7,8,10,11,12,14,19,20,24,27,29,31,34,35,37,38,39,40,41,42,43,44,45,46,47,48,49,50,51,52,53,54,55,57,58,59,60,61,62,66,72,80,83,84,87,88,90,93,95,99,102,103,104,134,135,136,137,140,141,142,144,156,158,160,161,162,164,167,170,171,173,174,179,180,185,194,197,202,212,213,215,216,218,221,226,229,230,231,232,235,236,238,239,241,243,244,247,248,251,252,253,254,259,261,264,266,268,274,275,277,278,279,280,281,285,286,287,288,291,292,296],onlin:[249,250,266,292,299,300],onto:[1,20,42,43,47,99,267,269,270,271,272,273,284,285,288,295,298],oob:[20,27,29],opaqu:[88,158,212,213,215,217,292],open:[4,8,9,10,12,20,21,38,39,47,55,57,58,59,61,102,138,140,158,159,163,164,166,167,169,170,173,174,175,176,177,178,181,185,214,253,264,266,269,270,272,273,277,285,290,296],open_test:[253,277],openocd:[12,99,266,269,270,272,273,298],openocd_debug:[269,285],oper:[1,9,12,15,18,20,21,26,31,39,57,58,59,84,85,90,92,95,102,103,104,106,136,138,140,158,166,167,168,173,175,179,180,184,185,186,187,189,191,193,200,213,218,230,232,241,253,254,256,257,261,262,263,264,265,266,274,277,278,280,281,284,285,288,292],oppos:[31,93,281],opt:4,optim:[1,24,32,37,38,43,50,61,93,99,100,107,140,229,242,251,254,256,257,260,266,269,270,271,272,273,274,278,285,286,288,292,295,298],optimis:31,option:[2,3,4,6,7,8,10,12,22,23,27,36,37,46,51,55,62,66,72,84,85,88,99,134,138,140,156,157,204,213,215,216,221,229,231,232,233,238,252,256,257,263,266,270,272,274,278,279,280,285,286,288,298],orang:[269,273],order:[1,8,9,22,33,55,61,63,86,90,91,94,103,105,107,134,135,138,185,213,231,232,243,248,249,250,251,253,274,277,280,282,285,286,292,299,300],org:[1,4,10,11,39,57,58,59,61,80,82,107,136,143,249,250,264,266,269,270,272,273,277,285,286,292,299,300],organ:[11,140,230,253,277,279],origin:[11,46,99,134,272,285],os_align:[84,90,91],os_arch:[61,91,106],os_arch_arm:196,os_arch_ctx_sw:86,os_bsp_adc0:286,os_bsp_adc0_config:286,os_callout:[61,85,88,103,135,246,268,292],os_callout_func:[85,92],os_callout_func_init:85,os_callout_func_t:85,os_callout_init:[85,103,246,268,292],os_callout_reset:[85,103,246,268,292],os_callout_stop:85,os_cfg:61,os_cli:232,os_cputim:61,os_cputime_delay_nsec:[84,87],os_cputime_delay_tick:[84,87],os_cputime_delay_usec:[84,87],os_cputime_freq:24,os_cputime_get32:[84,87],os_cputime_init:[84,87],os_cputime_nsecs_to_tick:[84,87],os_cputime_ticks_to_nsec:[84,87],os_cputime_ticks_to_usec:[84,87],os_cputime_timer_init:[84,87],os_cputime_timer_num:[24,87],os_cputime_timer_rel:[84,87],os_cputime_timer_start:[84,87],os_cputime_timer_stop:[84,87],os_cputime_usecs_to_tick:[84,87],os_dev:[61,140,213,214,215,286,290],os_dev_clos:[214,290],os_dev_cr:[140,213,214,215,218,286],os_dev_init_func_t:[140,215],os_dev_init_kernel:286,os_dev_init_primari:214,os_dev_init_prio_default:286,os_dev_open:[214,286,290],os_einv:211,os_eno:135,os_error_t:84,os_ev:[85,88,92,103,135,136,246,268,292],os_event_fn:88,os_eventq:[61,85,88,92,103,136,223,246,284,285,286],os_eventq_design:88,os_eventq_dflt_get:[26,95,105,136,232,246,264,265,268,290,292],os_eventq_dflt_set:285,os_eventq_get:[88,103],os_eventq_init:[88,92,103,136,246,284,285],os_eventq_put:[88,136,246],os_eventq_run:[26,88,92,95,105,232,246,264,265,268,285,290,292],os_exit_crit:84,os_fault:61,os_get_return_addr:84,os_get_uptime_usec:[84,106],os_gettimeofdai:[84,106],os_heap:61,os_idle_prio:84,os_info_init:84,os_init:[84,105],os_init_idle_task:84,os_main_stack_s:84,os_main_task_prio:[84,232,251],os_main_task_stack_s:232,os_malloc:[61,89],os_mbuf:[61,90,92,224,225],os_mbuf_append:[90,284,286],os_mbuf_copydata:90,os_mbuf_copyinto:90,os_mbuf_data:90,os_mbuf_free_chain:[90,92],os_mbuf_get:90,os_mbuf_get_pkthdr:90,os_mbuf_pkthdr:[90,92],os_mbuf_pool:90,os_mbuf_pool_init:90,os_mbuf_pullup:90,os_membloc:91,os_memblock:91,os_memblock_get:91,os_memblock_put:91,os_membuf_t:[90,91],os_mempool:[61,90,91],os_mempool_byt:91,os_mempool_info:91,os_mempool_info_name_len:91,os_mempool_init:[90,91],os_mempool_s:[90,91],os_mqueu:92,os_mqueue_get:92,os_mqueue_init:92,os_mqueue_put:92,os_msys_regist:93,os_mutex:[61,84,94,146,213],os_mutex_pend:94,os_mutex_releas:[84,94],os_ok:84,os_pkg_init:232,os_san:61,os_sanity_ch:103,os_sanity_check:[84,103],os_sanity_check_func_t:103,os_sanity_check_init:103,os_sanity_check_regist:103,os_sanity_check_setfunc:103,os_sanity_task_checkin:103,os_sch:[61,84,86],os_sched_ctx_sw_hook:[84,86],os_sched_get_current_t:251,os_sched_get_current_task:[84,86,103,251],os_sched_insert:[84,86],os_sched_next_task:[84,86],os_sched_os_timer_exp:[84,86],os_sched_remov:[84,86],os_sched_resort:[84,86],os_sched_set_current_task:[84,86],os_sched_sleep:[84,86],os_sched_wakeup:[84,86],os_sched_wakeup_tick:84,os_sem:[61,95,104,285],os_sem_init:[95,104,285],os_sem_pend:[95,104,285],os_sem_releas:[95,104,285],os_sem_test_bas:237,os_sem_test_case_1:237,os_sem_test_case_2:237,os_sem_test_case_3:237,os_sem_test_case_4:237,os_sem_test_suit:237,os_settimeofdai:[84,106],os_stack_align:[251,284,285,286],os_stack_t:[84,103,105,224,246,251,284,285,286],os_start:[84,96,105],os_stime_t:84,os_sysview:[250,300],os_task:[61,84,88,94,95,103,104,105,246,251,284,285,286],os_task_count:84,os_task_flag_evq_wait:84,os_task_flag_mutex_wait:84,os_task_flag_no_timeout:84,os_task_flag_sem_wait:84,os_task_func_t:[84,103],os_task_info:[84,105],os_task_info_get_next:[84,105],os_task_init:[84,95,103,105,246,251,284,285],os_task_list:84,os_task_max_name_len:84,os_task_obj:84,os_task_pri_highest:[84,105],os_task_pri_lowest:84,os_task_readi:84,os_task_remov:84,os_task_sleep:84,os_task_st:84,os_task_stailq:84,os_task_state_t:84,os_test:61,os_test_restart:240,os_tick_idl:[196,266,269,292],os_tick_init:196,os_ticks_per_sec:[85,103,106,135,196,215,246,251,268,284,285,286,292],os_tim:[61,84,253,277],os_time_adv:[84,106],os_time_delai:[84,105,106,215,246,248,251,284,286],os_time_get:[84,106],os_time_max:84,os_time_ms_to_tick:[84,106],os_time_t:[84,103,106,196,213,215],os_time_tick_geq:[84,106],os_time_tick_gt:[84,106],os_time_tick_lt:[84,106],os_timeout:285,os_timeout_nev:[84,95,214,290,292],os_timeradd:[84,106],os_timersub:[84,106],os_timev:[84,106,253,277],os_timezon:[84,106,253,277],os_wait_forev:[84,95,105,246,251,284,285],oscallout:85,osev:88,osmbuf:90,osmempool:91,osmqueu:92,osmsi:93,osmutex:94,ossan:103,ossem:104,ostick:84,osx:[242,248],ota:243,otg1:272,otg2:[272,298],other:[1,6,10,11,20,22,24,29,31,50,55,61,84,85,88,90,91,92,93,95,99,100,103,104,105,106,134,135,136,140,158,159,167,170,175,179,180,182,185,191,194,212,215,217,221,229,230,232,242,244,246,249,250,251,253,256,257,258,259,261,262,266,267,268,269,275,277,279,284,286,287,288,289,292,294,299,300],otherwis:[90,95,98,105,148,150,153,279,280],oti_cswcnt:84,oti_last_checkin:84,oti_nam:84,oti_next_checkin:84,oti_prio:84,oti_runtim:84,oti_st:84,oti_stks:84,oti_stkusag:84,oti_taskid:84,oui:[19,274],ount:90,our:[20,55,92,99,229,230,242,243,248,251,253,256,259,264,265,267,268,277,280,284,285,286,295,298],our_id_addr:[30,260],our_id_addr_typ:260,our_key_dist:27,our_ota_addr:[30,260],our_ota_addr_typ:[30,260],out:[8,9,10,11,20,21,22,23,26,27,61,80,81,82,85,90,101,134,136,142,146,147,150,152,166,167,179,186,187,205,207,208,209,210,229,233,240,254,256,258,260,264,265,267,272,278,285,297],out_data:[168,169],out_dir:[167,168,170],out_fil:[166,168],out_id_addr_typ:30,out_len:[163,168,169,177],out_nam:[142,162,168],out_name_l:162,out_name_len:[162,168],out_tick:84,outdat:58,outfil:[1,34,35,37,38,39,40,41,42,43,44,45,46,47,48,49,50,51,52,53,54,57,58,59,62,285],outgo:225,outlin:5,output:[1,7,12,21,22,27,30,34,35,37,38,39,40,41,42,43,44,45,46,47,49,50,51,52,54,57,58,59,62,69,73,75,76,77,81,85,88,90,91,92,93,94,99,103,104,105,134,135,187,193,212,229,231,233,242,246,249,253,254,266,268,269,270,272,273,274,277,278,285,288,292,296,299],outsid:[20,21,90],outweigh:90,over:[20,21,22,23,27,29,31,65,66,67,68,69,70,71,72,73,74,75,76,77,92,134,139,140,142,146,148,156,194,200,212,229,243,249,251,254,261,267,268,270,274,278,284,285,287,288,289,291,294,297,299,302],overal:[10,24,179],overhead:90,overlap:[20,185],overrid:[50,61,64,65,66,67,68,69,70,71,72,73,74,75,76,77,80,81,82,99,212,229,230,243,257],overridden:[23,232,257],oversampl:286,overview:[134,288,289,292],overwrit:[6,49,50,59,60,82,83,99,136,185,244,254,266,275,278],overwrite_many_test:[253,277],overwrite_one_test:[253,277],overwrite_three_test:[253,277],overwrite_two_test:[253,277],overwritten:[134,178,185],own:[2,11,19,20,39,57,58,59,61,94,95,102,104,105,141,185,197,212,229,230,252,255,256,285,286],own_addr_t:[264,265],own_addr_typ:[27,66,264,265],owner:[94,281],ownership:[94,185,285,286],pacakg:256,pacif:106,pack:[4,55,81,90,247,254,269,271,278,288,292,295],packag:[6,9,11,23,24,26,34,39,40,41,43,45,50,51,52,53,55,56,58,59,60,79,83,88,95,100,105,134,135,137,138,140,143,144,158,168,179,187,189,202,203,206,214,215,218,219,220,221,229,230,237,238,239,242,246,257,267,268,269,274,276,279,280,286,289,290,291,302],package1:212,package1_log:212,package2:212,package2_log:212,packet:[20,21,27,29,92,221,225,264,274],packet_data:90,pacman:[7,59],pad:[90,94,104,134],page:[1,4,5,6,7,8,10,20,22,57,58,60,80,81,83,99,107,141,186,194,195,213,214,215,216,242,248,252,256,258,262,264,265,267,286],page_s:141,pair:[20,21,22,27,66,134,135,185,206,211,232,260,262],pakcag:221,panel:12,param:[27,221,226,262],param_nam:221,paramet:[1,20,26,27,28,30,61,66,72,84,103,106,142,146,156,212,214,215,221,232,243,253,259,261,262,263,264,265,277],parameter_nam:232,parameter_valu:232,parent:[160,161,162,167,170,172,178,185],parenthes:90,pariti:200,parlanc:11,parmaet:27,parmet:[27,28],pars:[55,204,221,233,236,253,264,277],part:[22,29,90,101,134,146,174,179,180,185,186,229,259,260,263,285,286,291],parti:[254,264,266,278],partial:[64,65,66,67,68,69,70,71,72,73,74,75,76,77,80,81,82,134,179,180],particular:[4,20,47,61,95,99,102,103,134,136,140,158,187,197,199,206,240,262,264,265],particularli:[244,275],partit:[20,99,134,179,185,229],pass:[1,7,12,20,27,61,84,88,90,103,136,140,141,145,146,156,166,169,177,185,194,206,213,214,215,217,221,224,234,235,236,237,253,259,263,264,265,277,286,292],passiv:27,passkei:[20,22,27],password:[11,58,80,257,281],past:[20,286],patch:[269,270,273],path:[2,4,6,10,11,12,29,50,57,58,59,60,61,66,80,81,82,83,99,100,158,165,166,167,168,172,175,177,178,232,279,285,286],pathloss:29,pattern:[27,99,251],payload:[90,138,139,194],pc6:298,pc7:298,pca100040:257,pca:[247,271,286],pcb:285,pci:[140,187],pcmcia:[140,187],pdf:[242,298],pdt:[106,253,277],pdu:[20,27],peek:251,peer:[10,22,28,66,247,261,263,264,265],peer_addr:[27,30,66,259],peer_addr_typ:[27,30,66,259],peer_id:66,peer_id_addr:260,peer_id_addr_typ:260,peer_nam:[66,247],peer_ota_addr:260,peer_ota_addr_typ:260,pem:[37,46],pencil:10,pend:[20,88,94,134,194,247],per:[11,19,90,94,134,135,179,193,230,251,253,277,280,285],perfom:134,perform:[3,4,5,9,11,12,20,22,25,27,36,57,58,59,64,80,81,82,84,90,95,96,99,103,105,107,134,136,141,157,158,172,185,194,218,229,232,242,247,261,266,268,269,274,280,284,285,286,287,288,289,292],perhap:279,period:[9,19,22,27,85,103,196,201,246,251],peripher:[9,20,21,24,26,29,30,99,102,140,187,188,194,197,230,247,255,256,259,262,263,264,284,285,286],perman:[71,134,185,229,247,259,262],permiss:[285,286],permit:[20,249,250,263,266,292,299,300],persist:[134,157],perspect:229,pertain:262,petteriaimonen:107,phdr:90,phone:[22,31],php:55,phy:[21,27],phy_opt:27,physic:[21,27,29,66,136,190,193],pick:[86,95,212,264,265],pictur:[242,269],pid:270,piec:[21,99,285],pig:252,pin:[7,8,20,99,102,105,140,187,190,193,197,213,242,246,254,268,269,272,274,278,285,286,288,292,298],ping:95,pinout:101,piqu:302,pitfal:90,pkcs15:134,pkg1:231,pkg2:231,pkg:[1,7,11,39,43,50,53,55,57,58,59,61,100,101,107,136,140,141,142,157,158,186,187,212,214,221,230,231,232,243,246,253,256,268,277,285,286,287,292],pkg_init_func1_nam:232,pkg_init_func1_stag:232,pkg_init_func2_nam:232,pkg_init_func2_stag:232,pkg_init_func:232,pkg_init_funcn_nam:232,pkg_init_funcn_stag:232,pkg_test:239,pkga_syscfg_nam:232,pkga_syscfg_name1:232,pkga_syscfg_name2:232,pkgn_syscfg_name1:232,pkt:285,pkts_rxd:92,place:[3,55,61,85,107,134,146,174,229,232,238,243,248,251,256,257,263,264,265,272,280,285,294],plai:[12,21,294],plain:[229,270,280],plan:[2,140,221],platform:[2,7,9,11,12,23,24,57,58,59,66,80,81,82,85,95,99,100,102,140,199,238,247,251,254,256,266,268,269,270,272,273,278,285,286,288,295,296,297,298],pleas:[10,39,57,58,59,100,101,213,217,218,230,242,248,249,250,266,267,279,286,292,299,300],plenti:[251,285],plist:61,plu:[90,162,185,194],plug:[8,186,242,272,273,285,286],plumb:284,pmode:288,point:[2,4,6,31,86,90,94,99,101,105,107,134,136,140,147,148,149,150,151,153,154,155,156,167,168,170,185,213,256,261,262,264,265,285,286,287],pointer:[67,84,85,86,88,90,91,94,99,105,106,136,140,146,147,148,156,159,161,162,163,164,166,168,169,174,176,177,178,185,186,194,199,204,205,206,212,213,214,215,218,221,222,223,226,227,233,251,261,262],poke:286,polici:[27,279],poll:[95,217,288,292],poll_du:288,poll_dur:288,poll_interv:288,poll_itvl:288,poller:[213,217,218,292],pong:95,pool:[73,80,93,95,274,289,296],popul:[1,7,12,50,62,106,181,185,238,254,267,278,294,297,302],port:[2,12,66,95,136,140,193,200,212,230,243,254,257,266,268,269,270,271,272,273,278,285,288,292,295,296,297,298,302],portabl:[140,187],portingto:100,portion:[134,152,194,284,286],posit:[106,134,164,174,177,272],posix:59,possibilti:[249,250,299,300],possibl:[21,22,24,27,28,30,32,36,53,90,94,106,134,140,158,179,180,185,187,212,229,230,249,263,279,288,299],post:[49,92,140,246,256],potenti:[102,229,280],pour:[58,81],power:[2,9,20,21,22,27,29,31,55,99,102,136,140,187,215,243,247,254,257,266,271,272,274,278,287,288,289,290,292,295,298],ppa:4,pre:[4,9,212,230,279,280],precaut:261,preced:23,precis:[6,20],predict:251,preempt:[94,95,104,105],preemptiv:[95,105,251],prefer:[3,27,29,144,247,261,285],preference0x01:27,prefix:[61,185,216,232,286],prepar:[20,269,271,274,286],preprocessor:[221,230],prerequisit:12,presenc:[99,185,259,264,265,279],present:[1,90,93,99,134,136,185,202,214,229,253,257,272,277,286],press:[8,12,104,246,250,251,256,278,285,288,300],presum:[90,92,274],pretti:286,prev:185,prev_ind:262,prev_notifi:262,prevent:[94,95,134,175,261],previ:[260,262],preview:[252,257,271],previou:[21,56,57,58,59,78,79,80,81,82,134,185,206,231,232,256,257,268,279,284],previous:[6,12,57,58,59,60,80,81,82,83,197,243,260,282,286,288],prevn:[260,262],pri:[77,285,295,298],primari:[27,99,134,138,172,247,263,265,284],primarili:107,primary_phi:27,primo:[267,284,285],primo_boot:269,primo_debug:269,primoblinki:269,print:[48,57,58,59,62,135,136,142,160,161,162,167,170,177,221,231,233],print_statu:177,print_usag:204,printabl:205,printf:[107,142,233,236],prio:[103,196,224],prior:[22,24,49,95,97,134,172,181,185,197,274],prioriti:[77,84,86,88,94,95,97,104,105,140,179,189,196,232,246,257,286,302],priv:27,privaci:[19,21,27],privat:[19,22,32,37,46,57,66,80,134,264,265],privileg:2,pro:[251,266,269],probabl:[7,10,99,258,281,285],probe:[194,254,269,278,292],problem:[7,104,134,167,229,231],proce:[3,6,11,134,240,253,254,266,269,270,271,272,273,277,278,285,295,298],procedur:[6,11,16,19,20,22,27,28,64,75,80,81,82,134,185,186,229,288,291],proceed:[7,258,264,265],process:[3,6,9,10,20,22,26,27,31,61,85,86,88,92,99,105,134,136,137,185,218,219,223,229,230,232,242,243,246,249,250,251,264,265,287,290,291,292,299,300],process_data:175,process_rx_data_queu:92,processor:[4,9,90,105,140,187,193,249,250,251,266,272,292,299,300],produc:[104,134,230,236,270],product:[55,102,180,193,216,257,285,298],profil:[14,15,16,17,21,27,28,31,64,65,66,67,68,69,70,71,72,73,74,75,76,77,78,80,81,82,256,266,295,297,298],profile01:[65,67,68,69,70,71,72,73,74,75,76,77],profile0:77,program:[4,6,8,12,23,86,134,136,195,242,251,254,266,268,269,271,274,278,286],programat:136,programm:[249,250,270,299,300],programmat:[143,292],progress:[7,20,134,140,141,185,255],prohibit:173,project:[3,6,8,11,33,34,39,40,41,44,49,50,52,55,57,58,59,61,63,85,88,90,91,92,93,94,103,104,105,107,134,135,136,141,142,144,157,182,183,187,202,212,230,237,238,246,248,249,251,252,253,260,277,281,282,287,288,292,293,294,299,302],prompt:[7,8,11,12,47,58,59,99,256,266,268,269,270,271,272,273,285,288,292],prone:263,proper:[140,286],properli:[24,61,95,103,201,251,257,261,284,285,286],properti:[12,19,31,59,99,134,139,179,180,185,212,242,258,269],proport:185,propos:10,propper:285,prot_length:90,prot_tif:90,prot_typ:90,protcol:90,protect:[22,89,134,146],protocol:[14,20,21,28,61,66,90,134,138,139,194,289,291,294,297],prototyp:[88,102,232,264,265],provid:[1,2,7,9,11,12,19,20,21,22,27,30,31,37,39,45,50,57,58,59,66,70,71,72,75,80,87,89,90,91,94,95,99,101,102,103,106,134,136,140,141,142,146,157,158,179,187,194,204,213,216,218,219,221,230,238,241,243,253,254,258,264,265,266,274,277,278,279,280,285,286,291],provis:[21,32],provision:31,proxi:[21,31],pseln:286,pselp:286,pset:197,psm:27,psp:[266,270],pst:[68,106,253,277],pth:272,ptr:200,public_id:27,public_id_addr:30,public_target_address:29,publish:22,pull:[11,49,80,82,88,90,140,246,268,272],pullup:90,purpos:[4,22,50,55,99,103,134,187,193,212,215,217,229,230,251,261,274,286,292],push:[10,252],put:[1,2,7,43,61,80,82,88,92,94,99,104,105,106,139,251,253,259,264,265,277,286],putti:[8,254,268,278,288],pwd:[2,11],pwm:9,pwr:[270,272],px4:4,python:[33,63],qualifi:261,qualiti:293,quat:288,queri:[9,19,50,55,57,58,59,61,62,139,161,162,163,164,177,185,213,215,230,259,288,296],question:256,queu:[20,246],queue:[26,61,84,85,90,92,94,95,103,104,105,136,185,199,218,221,223,225,232,243,264,265,284,290,292,294,302],quick:[2,3],quickli:[106,187,251,286,288,291,292,294],quickstart:[2,251],quiet:[1,34,35,37,38,39,40,41,42,43,44,45,46,47,48,49,50,51,52,53,54,57,58,59,62,285],quit:[19,99,249,256,259,264,265,266,269,270,272,273,299],quot:66,r_find_n:218,r_lock:218,r_match_:218,r_regist:218,r_unlock:218,radio:[21,24,257],raff:81,rais:94,ram:[48,99,101,179,229,256,266,285,286,287],ram_siz:99,rand:27,random:[19,20,25,27,30,66,257,263,264,265,284],random_id:27,random_id_addr:30,randomli:19,rang:[9,20,21,29,107,185,204,274],rare:90,rate:[66,85,136,218,219,257,274,288,291,292],rather:[14,20,99,107,134,158,172,229,286],raw:[11,57,58,59,80,81,82,136,179,185,232,233,286],rb_bletini:50,rb_blinki:[43,50],rb_blinky_rsa:43,rb_boot:43,rbnano2_blinki:273,rbnano2_boot:273,rdy:84,reach:103,read:[4,6,7,11,12,14,18,19,20,23,27,28,55,61,64,65,68,73,76,77,80,81,82,134,135,136,140,141,142,146,148,151,152,156,158,159,160,161,162,164,166,167,169,170,174,175,177,185,191,193,194,206,211,212,217,218,219,220,232,233,242,243,246,247,249,250,251,253,254,260,262,263,264,265,266,267,270,273,274,277,278,279,284,285,286,287,288,289,291,294,297,299,300],read_acceleromet:292,read_cb:292,read_chr:261,read_config:[159,166,169],read_part1_middl:174,read_rsp_rx:76,read_rsp_tx:76,read_sensor_interv:292,read_test:[253,277],read_type_req_rx:76,read_type_req_tx:[76,243],read_type_rsp_rx:[76,243],read_type_rsp_tx:[76,243],readabl:[257,281],readdesc:7,readdir_test:[253,277],reader:[253,277,284,286],readi:[10,84,86,88,105,136,206,249,251,266,285,299],readili:140,readm:[7,11,55,61,99,253,256,277],readnow:61,real:[1,7,9,88,95,136,185,206,241,246,249,256,263,292,299],realist:[253,277],realli:[90,286],rearm:85,reason:[10,20,26,27,90,91,134,251,253,260,262,274,277,279],reassembl:21,rebas:11,reboot:[7,71,134,229,231,247,287,289],reboot_log:72,reboot_log_flash_area:[231,232],reboot_start:290,rebuild:[32,61,82,290],rec0:134,rec1:134,rec2:134,recal:[261,279],receiv:[10,14,20,27,29,31,55,81,92,136,137,142,194,200,213,218,221,224,227,243,259,262,263,270,274,292,295,298],recent:[185,269],recip:6,recipi:29,reclaim:185,recogn:[55,185,286],recommend:[3,4,7,12,57,58,80,81,90,136,195,214,215,221,231,232,243,244,246,249,259,263,269,273,275,288,294,299],reconfigur:[197,200,290],reconnect:261,record:[134,185,215,230,238,250,300],recov:134,recover:134,recreat:280,recur:201,recurs:[55,61,175],red:[27,28,242,270,272,298],redbear:[267,302],redefin:231,redistribut:[55,249,250,266,279,292,299,300],reduc:[9,22,24,31,88,107,138,212,243,246,276],redund:229,reenter:[244,275],ref0:67,refer:[7,8,10,18,22,23,29,55,67,90,99,172,175,185,197,216,222,226,229,252,254,259,264,265,266,268,272,278,285,286,288,298],referenc:[1,185,193],reflect:260,reformat:185,refrain:26,refresh:[2,49,252,266],refus:[249,292,299],regard:[179,180,253,277,285,286],regardless:41,region:[99,134,173,179,180,185],regist:[23,75,86,93,100,135,137,140,144,158,168,171,187,194,203,212,213,217,219,222,224,226,227,228,232,251,261,263,285,286,292],register_:217,registr:[17,186,230,261,292],registri:215,regress:[234,235,237,238,239],regular:[161,253,277],reject:[20,253,277],rel:[84,95,154],relai:[21,31],relat:[10,27,31,43,141,229,249,250,259,262,266,274,292,299,300],relationship:[27,104],releas:[3,4,7,31,49,56,78,79,94,95,104,140,194,221,232,254,266,278,279,280],release_not:[7,11],relev:[101,134,140,193],reli:[1,7,55,232],reliabl:[21,134,157,179,264,265,280],remain:[99,169,175,185,229,233,236,251,261],remaind:[99,185,236,253,259,277,279],rememb:[2,41,80,82,94,266,284],remind:266,remot:[1,7,9,12,20,27,28,49,55,66,78,80,81,82,138,242,243,246,247,254,257,266,267,268,278,285,286,292,294,296,297,302],remov:[2,4,6,27,35,45,60,83,84,88,92,104,136,142,185,229,261,266,292],renam:172,rename_test:[253,277],repeat:[2,11,20,194,248,261],repeatedli:[29,134],replac:[4,6,99,101,107,202,229,232,233,236,248,266,268,284,295,298],repli:27,repo814721459:55,repo:[1,6,7,10,11,41,55,57,61,80,99,140,158,193,229,242,249,250,252,253,254,256,266,268,269,270,271,272,273,274,277,278,281,285,286,287,288,292,295,296,298,299,300],repop:7,report:[1,4,6,10,20,99,230,233,236,249,250,253,266,270,277,285,292,299,300],reposistori:7,reposit:174,repositori:[1,4,11,12,40,41,44,49,51,52,57,61,80,140,242,252,254,255,256,258,266,267,274,278,282,285,294,297,302],repres:[1,12,61,87,106,134,136,165,185,213,215,217,218,221,251,263],represent:[134,138],reproduc:[1,61,134,186,264,265],req_api:[61,136,212],request:[12,20,27,66,67,74,78,91,93,94,99,104,134,138,139,142,146,169,185,216,217,219,221,229,243,260,261,266,270,272,274,279,280,284,286,287,291,292,295,298],requir:[1,2,4,6,9,11,20,24,30,31,53,59,61,66,80,82,88,90,91,95,100,101,102,104,134,136,138,141,158,168,179,180,185,199,212,214,221,229,230,231,232,235,242,243,246,251,253,256,259,261,266,269,273,274,277,279,280,284,285,286,288,290,291,292,302],res:287,resch:84,reserv:[20,90,99,102,147,149,185,213,251,274],reserved16:185,reserved8:185,reset:[25,64,78,80,81,82,94,103,137,138,198,229,240,243,249,250,256,257,260,269,270,271,273,286,288,292,299,300],reset_cb:26,reset_config:266,reset_handl:[99,272],resid:[102,134,180,185,248,263,285],resign:[57,58,59],resist:286,resistor:[246,286],resolut:[22,87,230,286],resolv:[1,19,20,22,27,32,55,66,81,231,242,264,265,279],resourc:[9,20,29,61,89,94,104,139,216,217,219,221,242,246,249,250,266,287,289,291,292,298,299,300],respect:106,respond:[17,25,229,259,261,263,284,285],respons:[10,15,20,28,29,69,86,95,136,138,142,219,229,251,254,259,261,278,285,291,295,296,298],rest:[1,46,61,90,185,204,206,233],restart:[2,134,135,146,185,266],restor:[135,179,182,183,185,269,271,274,286],restrict:[134,146,179,180,185,221,232,261,262],restructuredtext:10,result:[10,12,20,58,62,106,166,167,180,185,205,213,230,232,236,238,253,263,270,277,284,285,286],resum:[21,105,134,185,259,262],resynchron:49,retain:[134,185,232,262],retransmit:31,retreiv:139,retri:[273,274],retriev:[57,80,106,138,158,160,161,162,163,164,167,169,170,177,180,213,215,256,294],reus:[55,81,134,232],reusabl:55,rev:288,revdep:[1,50,62],revers:[1,23,50,62,134,185,261,272],revert:[134,247],review:[10,229,253,259,277],revis:[4,204,288],revision_num:[279,280],revisit:[256,262],rewrit:185,rewritten:185,rfc:[68,206,253,277],ribbon:[272,298],rigado:[48,271,286],right:[2,3,10,55,61,84,135,252,259,272,286],rimari:263,ring:104,ristic:263,rite_fil:158,robust:157,role:[20,21,30,31,104,261],room:[185,251],root:[2,4,8,31,80,142,171,185,242,279],rotat:172,rotate_log:172,routin:[84,107,135,146,147,149,168,186,206,237,285],rpa:[19,27],rpa_pub:[27,66],rpa_rnd:[27,66],rsa2048:134,rsa:134,rsp:27,rssi:[27,29,257],rtc:9,rto:[55,95,251],rtt:[136,301,302],rtt_buffer_size_down:[249,299],rubi:[11,55,58],rule:[232,253,270,277],run:[2,3,4,5,6,8,9,11,23,24,30,34,39,41,43,50,52,55,57,58,59,60,61,64,66,67,77,78,80,81,82,83,84,85,86,88,94,95,99,102,103,104,105,134,135,137,138,141,142,158,166,167,185,199,201,219,221,227,229,231,239,240,241,242,243,247,248,251,253,254,256,257,264,265,267,269,270,271,272,273,274,277,278,285,286,287,288,289,290,292,295,297,298,302],runner:12,runtest:[7,137,243],runtest_newtmgr:243,runtim:[25,77,254,266,278,285,295,298],runtimeco:[57,58,59,80,81,82,242,254,266,278,279,286],rwx:99,rwxr:[80,82],rx_cb:136,rx_data:285,rx_off:285,rx_phys_mask:27,rx_power:27,rxpkt:90,rxpkt_q:92,s_cnt:230,s_dev:213,s_func:213,s_hdr:230,s_itf:213,s_listener_list:213,s_lock:213,s_map:230,s_map_cnt:230,s_mask:213,s_name:230,s_next:[213,230],s_next_run:213,s_pad1:230,s_poll_rat:213,s_size:230,s_st:[213,292],s_type:213,saadc_config_irq_prior:286,saadc_config_oversampl:286,saadc_config_resolut:286,sad:292,sad_i:292,sad_x:292,sad_x_is_valid:292,sad_y_is_valid:292,sad_z:292,sad_z_is_valid:292,safe:158,safeguard:95,safeti:261,sai:[61,93,105,254,266,278,279,280,285],said:[193,286],sam0:266,sam3u128:[269,271,274,286,292],samd21:[254,266,278],samd21g18a:266,samd21xx:266,samd:266,same:[6,10,12,22,29,34,37,47,51,59,61,78,90,93,94,99,100,104,134,136,157,179,185,194,218,229,230,231,232,233,242,246,248,251,259,261,262,267,269,271,274,279,280,281,286,287],sampl:[1,12,21,30,61,90,92,100,140,219,229,232,286,287,289,291,292,297],sample_buffer1:286,sample_buffer2:286,sample_cmd:228,sample_cmd_handl:228,sample_command:226,sample_modul:[226,228],sample_module_command:226,sample_module_init:226,sample_mpool:226,sample_mpool_help:226,sample_mpool_param:226,sample_target:53,sample_tasks_help:226,sample_tasks_param:226,saniti:[77,95,256],sanity_interv:103,sanity_itvl:103,sanity_task:103,sanity_task_interv:103,satisfactori:279,satisfi:[185,280],sattempt_stat:230,save:[12,31,49,50,71,106,135,136,194,215,251,261],saw:262,sbrk:[99,269,270,271,272,273],sc_arg:103,sc_checkin:103,sc_checkin_itvl:103,sc_checkin_last:103,sc_cmd:[221,222,226,227,228,285],sc_cmd_f:221,sc_cmd_func:[221,222,226,227,228,285],sc_cmd_func_t:221,sc_func:103,sc_next:[103,158],sc_valtyp:213,scalabl:[157,185],scale:31,scan:[15,21,24,26,27,29,185,257,259,287,289],scan_interv:27,scan_req:27,scan_req_notif:27,scan_result:[254,278],scan_rsp:27,scan_window:27,scannabl:[27,30],scenario:[22,104,202],scene:31,schedul:[9,24,88,95,96,97,102,105,106,251],schemat:[99,298],scheme:[19,29,99],scientif:21,sck_pin:[141,142],scl:[194,288],sco:20,scope:[12,90,251],scratch:[99,134,146,147,149,229],screen:[8,274],script:[7,42,61,143,145,272],scroll:[12,243,260],sd_get_config:[213,215],sd_read:[213,215],sda:[194,288],sdcard:142,sdk:[45,53,232],search:[12,100,140,182,185,218,249,250,256,266,272,279,287,292,299,300],searchabl:140,sec000:134,sec125:134,sec126:134,sec127:134,sec:[288,292],second:[22,26,27,61,64,65,66,67,68,69,70,71,72,73,74,75,76,77,80,81,82,85,91,99,103,105,106,134,146,201,221,229,242,248,251,253,259,264,265,268,272,277,284,285,286,288,292],secondar:263,secondari:[27,71,99,134,247,263,285],secondary_phi:27,secret:[22,27],section:[1,5,6,7,11,12,14,24,25,29,30,61,95,99,105,134,185,215,229,231,232,243,247,251,254,255,259,262,263,266,267,278,279,280,286,294,296,297],sector:[134,146,147,152,154,155,156,185,191,272],sector_address:141,secur:[21,134,229,263,281,284],see:[2,4,5,6,7,8,10,11,12,21,22,23,24,33,36,43,55,57,58,59,61,63,64,66,80,81,82,85,88,89,94,95,99,102,105,134,143,153,166,187,194,197,206,212,213,214,215,216,217,218,219,220,221,230,231,232,242,243,244,247,248,249,250,251,252,254,256,257,259,260,261,263,264,265,266,267,268,269,270,271,272,273,274,275,278,279,280,281,284,285,286,287,288,289,291,292,294,295,297,298,299,300],seek:[174,185],seem:[259,286],seen:[91,192,195,196,201,279,302],segger:[136,247,254,269,271,274,278,286,288,292,295,301,302],segger_rtt_conf:[249,299],segment:[21,287],sel:298,select:[4,12,19,21,55,59,185,193,197,213,221,250,266,268,269,270,272,287,289,298,300],selector:213,self:[3,30,100,253,264,265,277],selftest:[253,277],sem_head:104,sem_token:104,sema:285,semant:262,semaphor:[95,105,285],semi:285,send:[3,10,14,20,27,28,31,38,42,47,64,66,67,69,74,78,80,81,82,90,136,138,139,194,200,219,241,242,248,259,267,284,286,291,296,302],send_pkt:90,sender:259,sens:[20,134,229,286],senseair:[284,285],senseair_cmd:285,senseair_co2:[284,285],senseair_init:285,senseair_read:[284,285],senseair_read_typ:[284,285],senseair_rx_char:285,senseair_shell_func:285,senseair_tx:285,senseair_tx_char:285,sensi:287,sensibl:232,sensor:[9,31,140,230,302],sensor_accel_data:292,sensor_callout:292,sensor_cfg:[213,215],sensor_cli:[220,288,289,292],sensor_cr:[214,288,290],sensor_data_func_t:[215,217],sensor_data_funct_t:215,sensor_dev_cr:214,sensor_devic:213,sensor_driv:[213,215],sensor_ftostr:292,sensor_g:213,sensor_get_config_func_t:[213,215],sensor_get_itf:215,sensor_in:213,sensor_init:[213,215],sensor_itf:[213,214,215],sensor_itf_i2c:[213,214],sensor_itf_spi:213,sensor_itf_uart:213,sensor_listen:[213,217,292],sensor_lo:213,sensor_mg:218,sensor_mgr_find_next_bydevnam:[218,292],sensor_mgr_find_next_bytyp:218,sensor_mgr_l:218,sensor_mgr_lock:218,sensor_mgr_match_bytyp:218,sensor_mgr_regist:[213,215,218],sensor_mgr_unlock:218,sensor_mgr_wakeup_r:[218,292],sensor_nam:288,sensor_o:[219,287,288,289,291,292],sensor_offset:288,sensor_oic_init:[219,287],sensor_oic_obs_r:[219,291],sensor_r:[213,217],sensor_read:[213,217],sensor_read_func_t:[213,215],sensor_register_listen:[217,292],sensor_s:213,sensor_set_driv:[213,215],sensor_set_interfac:[213,215],sensor_set_poll_rate_m:[213,218,292],sensor_set_type_mask:[213,215],sensor_shel:288,sensor_timestamp:213,sensor_type_acceleromet:[213,214,215,290,292],sensor_type_al:213,sensor_type_eul:[215,290],sensor_type_grav:[215,290],sensor_type_gyroscop:[213,215,290],sensor_type_light:213,sensor_type_linear_accel:[215,290],sensor_type_magnetic_field:[213,215,290],sensor_type_non:213,sensor_type_rotation_vector:[215,290],sensor_type_t:[213,215,217,218,292],sensor_type_temperatur:[213,215],sensor_type_user_defined_6:213,sensor_un:[213,217],sensor_unregister_listen:[217,292],sensor_value_type_float:[213,215],sensor_value_type_float_triplet:[213,215],sensor_value_type_int32:213,sensor_value_type_int32_triplet:213,sensor_value_type_opaqu:213,sensor_value_type_temperatur:215,sensornam:[213,214,215,216,288,290,292],sensorname_cli:215,sensorname_ofb:288,sensors_o:289,sensors_test:[287,288,290,291],sensors_test_config_bno055:290,sent:[20,29,136,185,200,221,261,263,274],sentenc:[62,252],sep:[4,81,82],separ:[20,26,34,35,50,51,66,134,140,182,185,188,204,212,229,230,261,264,265,266,269,270,272,273,274],seper:[249,299],sequenc:[95,134,136,179,185,233,236],sequenti:[179,180,185],seri:[134,165,198,263,302],serial:[10,66,88,134,135,136,138,139,140,146,194,197,230,243,246,247,269,273,274,285,287,288,289,296,297],serror_stat:230,serv:[18,55,99,146,216,229,287],server:[12,14,18,20,21,27,31,139,216,217,219,229,252,263,274,284,287,289,291,292],servic:[16,17,21,27,28,29,31,95,102,140,187,241,254,259,260,261,262,278,280,285,287],service_data_uuid128:[27,29],service_data_uuid16:29,service_data_uuid32:[27,29],sesnor:292,session:[12,38,39,47,55,57,58,59,61,99,249,266,269,270,272,273,299],set:[1,2,7,8,9,10,12,19,20,23,24,27,28,29,31,32,34,36,37,39,50,53,55,56,58,59,61,62,64,65,66,67,68,69,70,71,72,73,74,75,76,77,79,81,82,84,85,87,88,90,93,102,103,104,105,106,134,135,136,140,141,151,158,159,163,166,168,169,173,176,179,181,182,183,185,187,193,194,196,197,200,201,206,214,216,218,219,220,221,222,226,227,228,229,230,238,242,244,246,247,249,251,253,254,257,260,261,264,265,266,267,269,270,271,272,273,274,275,277,278,279,280,281,284,286,288,289,291,292,294,295,297,298,299],setting1:231,setting2:231,settl:25,setup:[11,57,59,60,71,80,82,83,215,229,243,247,256,257,267,268,284,285,286,288,292,294,295,296,297,298],sever:[3,20,21,23,27,61,99,100,102,106,134,185,229,232,240,241,263,264,265,271,272,279],sha256:134,sha:134,shall:[24,27,29],share:[4,22,89,94,95,104,229,246,279],sheet:215,shell:[1,7,8,21,30,55,59,80,102,135,136,143,144,212,216,222,223,224,225,226,227,228,230,231,232,242,243,244,249,251,267,274,275,284,285,287,288,289,294,299],shell_cmd:[221,222,226,227,228,285],shell_cmd_argc_max:[221,274],shell_cmd_func_t:221,shell_cmd_h:221,shell_cmd_help:[221,226,244,275],shell_cmd_regist:[221,227,285],shell_compat:221,shell_complet:221,shell_evq:285,shell_init:232,shell_max_compat_command:[221,222],shell_max_input_len:144,shell_max_modul:[221,226],shell_modul:221,shell_newtmgr:[221,243],shell_nlip_input_func_t:224,shell_nlip_input_regist:221,shell_os_modul:[221,244,275],shell_param:[221,226],shell_prompt_modul:[221,268],shell_regist:[221,228],shell_sample_mpool_display_cmd:226,shell_sample_tasks_display_cmd:226,shell_stack:[144,285],shell_stack_s:285,shell_task:[221,231,232,243,244,268,275,285,288,292],shell_task_handl:285,shell_task_init:144,shell_task_prio:[144,285],shell_task_prior:231,shell_task_stack_s:144,shield:95,shift:[12,21],ship:[6,10],shortcut:[12,285],shorten:259,shorter:[185,248],shorthand:[90,279],shortli:286,shot:274,should:[4,8,10,12,19,26,30,32,55,57,59,61,81,84,85,86,88,99,102,103,104,105,134,136,140,143,144,146,152,156,158,162,163,166,176,179,185,187,194,199,200,201,204,206,215,218,221,230,232,236,238,242,248,249,250,251,253,254,257,259,260,261,262,264,265,266,268,269,270,271,272,273,274,277,278,279,282,285,286,287,288,290,292,295,298,299,300],show:[1,4,5,6,7,8,11,12,27,28,31,36,39,40,43,50,53,57,58,59,60,61,62,72,80,81,82,83,90,105,135,136,200,212,226,229,231,232,238,241,242,243,246,247,249,250,251,252,254,257,263,266,267,268,269,270,271,272,273,274,278,284,285,286,287,288,289,290,291,292,294,295,296,298,299,300,302],shown:[6,7,12,43,55,61,90,92,95,134,141,188,199,215,230,242,253,261,266,269,271,274,277,279,281,284,286,288,290,292,296],si_addr:[213,214],si_cs_pin:213,si_num:[213,214],si_typ:[213,214],sibl:[11,280],sid:27,side:[12,21,30,135,285],sierra:[58,81],sig:[20,29,31],sign:[6,10,37,46,47,57,58,59,80,213,248,257,267],signal:[20,21,26,29,105,197,262],signatuar:12,signatur:[27,46,134],signed_imag:134,signific:[19,90,229,274],significantli:31,signigic:90,silent:[1,34,35,37,38,39,40,41,42,43,44,45,46,47,48,49,50,51,52,53,54,57,58,59,62,232,285],silicon:32,sim1:[295,296,298],sim:[6,7,61,100,285,295,297,298],sim_slinki:[231,296],similar:[1,8,10,12,95,99,214,253,257,274,277,284],similarli:[93,212],simpl:[12,20,21,61,86,90,95,99,104,105,107,135,138,140,157,187,230,242,251,258,259,264,265,268,286,292,294],simplehttpserv:[33,63],simpler:[99,263],simplest:[90,295,298],simpli:[6,10,88,91,93,104,105,136,187,229,242,251,255,260,266,284],simplic:[134,264,265],simplifi:[20,88,91,194],simul:[2,3,5,6,50,240,251,292,296],simultan:[27,29,30],simultaneosli:158,sinc:[3,20,24,32,61,90,95,99,104,106,134,221,230,247,248,251,254,256,257,264,265,266,268,278,279,284,285,286,287],singl:[2,3,7,22,39,47,55,57,58,59,93,104,105,134,140,158,177,179,180,185,215,230,232,253,258,259,263,264,277,279],singli:185,sissu:198,sit:[14,18,140,187,229],site:[258,269,273],situat:[95,229],six:[22,23],size:[9,20,27,29,39,55,57,58,59,61,73,77,90,91,93,99,105,106,107,134,136,138,141,162,179,180,181,185,211,212,229,230,231,232,233,241,243,251,266,270,272,274,276,289],size_t:[162,168,206],sizeof:[90,135,142,159,160,161,162,166,167,169,170,177,211,214,233,251,259,261,262,265,284,285,286],skelet:257,skeleton:[7,44,50,242,254,256,257,266,269,270,271,272,273,274,278,286,295,296,298],skip:[6,11,47,59,134,146,148,254,266,269,270,271,272,273,278,295,298],sl_arg:[217,292],sl_func:[217,292],sl_next:217,sl_sensor_typ:[217,292],slash:185,slave:[27,29,194,197],slave_interval_rang:29,sleep:[9,84,86,88,92,94,104,105,106,246,251,268],slightli:[102,229],slink:[295,296,298],slinki:[7,45,61,136,158,182,183,229,231,232],slinky_o:[7,61],slinky_sim:231,slinky_task_prior:231,slist_entri:[84,90,103,158,185,213,217],slist_head:[84,91,94,104,213],slot0:134,slot1:134,slot:[7,20,61,71,202,229,244,247,249,250,254,257,260,266,268,269,270,271,272,273,274,275,278,285,288,292,295,298,299,300],slower:[3,102,103],small:[20,24,90,136,140,177,229,230,253,263,270,277,285,286],smaller:[10,90,93,138,201,229,252,266],smallest:[93,185],smart:[21,31,55,61,285,291],smarter:280,smp:[20,21],snapshot:[43,269,273,280],snip:[1,36,43,55,61,243,256,257,286],snippet:261,soc:102,socket:2,soft:[64,80,81,82,198],softwar:[1,3,4,6,21,38,42,47,50,102,103,134,187,241,247,249,254,266,269,271,272,278,279,285,286,288,292,295,299],solder:285,solut:[55,187,264,265],solv:[134,229],some:[1,8,12,30,64,76,90,91,92,95,99,102,104,105,107,134,136,142,146,157,158,159,166,169,179,180,212,226,231,238,242,243,244,249,250,251,253,254,258,259,260,261,262,264,265,268,269,270,273,274,275,277,278,279,285,286,292,295,298,299,300,302],somebodi:[135,285],somehow:61,someon:[10,86,286],someth:[20,242,249,254,256,257,278,281,299],sometim:[135,249,254,266,278,299],somewhat:[95,134,185],somewher:[134,185,229,286],soon:[21,280,286],sooner:201,sophist:251,sort:[185,260],sourc:[1,4,9,21,24,50,56,58,60,61,79,81,83,102,134,135,140,172,185,193,215,216,232,238,246,254,258,266,269,270,272,278,279,280,286,292,294,298],space:[12,21,34,35,50,51,66,90,102,146,147,162,179,180,202,205,221,229,230,254,256,264,267,278,294,297,302],spec:20,specfi:288,special:[8,90,102,141,229,233,236,253,263,264,265,277,278,279,280,285,288],specif:[11,20,21,22,23,29,31,57,58,59,61,62,84,86,88,90,91,95,99,101,102,106,134,138,140,156,158,179,180,187,193,194,196,198,199,202,212,213,215,229,232,233,237,238,243,251,253,254,257,259,261,262,264,265,266,272,274,277,278,279,285,286,295,298],specifi:[1,4,6,7,10,11,12,20,27,30,34,35,37,39,41,43,45,46,50,51,53,55,57,58,59,61,65,66,67,68,69,70,71,72,73,74,75,76,77,87,88,99,102,103,106,107,136,138,139,156,158,159,160,161,162,163,164,165,166,167,169,170,172,173,174,175,176,177,178,180,182,183,185,189,212,213,214,215,216,217,218,219,220,221,222,223,226,231,233,236,238,243,244,247,249,254,256,259,261,262,263,264,265,266,271,272,275,278,279,280,281,286,288,291,292,295,298,299],spectrum:21,speed:[9,21,185,200,249,266,269,270,271,274,286,299],spew:[254,278],sphinx:[33,63],spi:[8,21,102,140,141,142,193,197],spi_cfg:[141,142],spi_miso_pin:[141,142],spi_mosi_pin:[141,142],spi_num:[141,142,197],spi_sck_pin:[141,142],spi_ss_pin:[141,142],spitest:[7,61],split:[7,71,99,185,231,247,286,295,296,298],split_app:7,split_app_init:232,split_config:[295,296],split_elf_nam:61,split_file_test:[253,277],split_load:232,splitti:[7,61,229,231],spot:99,spread:21,spuriou:[253,277],squar:194,sram:272,src:[6,7,11,45,50,55,61,70,80,82,99,101,140,182,183,186,187,195,196,198,201,204,232,238,248,251,253,254,256,266,269,270,271,272,273,274,277,278,284,285,286,288,290,292,295,296,298],ss_op_wr:261,ss_pin:[141,142],ssec:27,sstatic:284,st_cputim:292,st_ostv:292,stabil:[279,280],stabl:[1,7,57,58,80,81,279,280],stack:[1,9,18,21,24,26,27,30,55,77,86,88,90,92,95,105,229,232,255,256,257,258,259,261,262,263,274,285],stack_len:224,stack_ptr:224,stack_siz:103,staff:[80,81],stage:[103,134,140,214,229,232],stai:[166,167],stailq_entri:[84,88,90,91,230],stailq_head:[84,88,92],stale:[2,266],stand:[93,239],standalon:[10,229],standard:[7,21,31,106,138,139,140,141,157,158,166,187,259,264,265,274,284,285],standbi:[21,202],start:[2,4,8,9,10,12,26,27,28,30,38,47,59,62,71,82,84,89,90,94,95,96,97,98,99,101,105,134,140,143,146,147,149,152,158,165,166,174,177,180,185,194,195,196,198,199,201,210,218,229,232,240,242,250,251,252,253,255,256,259,266,267,268,269,270,272,273,274,277,279,284,285,286,287,288,289,290,292,296,300,302],starter:248,startup:[19,21,26,30,134,229,232,251,264,265],startup_stm32f40x:[270,272],stash:49,stat:[1,7,64,78,80,81,82,137,138,232,243,244,249,256,274,275,285,286,292,299],state:[6,21,26,31,52,55,84,86,88,99,103,106,139,146,182,183,187,206,246,247,251,266,272,280,282],statement:[11,232,243],statist:[1,48,64,73,76,77,80,81,82,249,274,295,296,298,299],stats_cli:[1,244,275,285],stats_hdr:[215,230],stats_inc:230,stats_incn:230,stats_init:[215,230],stats_init_and_reg:230,stats_module_init:232,stats_my_stat_sect:230,stats_nam:[1,37,38,76,215,230],stats_name_end:[215,230],stats_name_init_parm:[215,230],stats_name_map:230,stats_name_start:[215,230],stats_newtmgr:[1,231,232,243],stats_regist:[215,230],stats_sect_decl:[215,230],stats_sect_end:[215,230],stats_sect_entri:[215,230],stats_sect_start:[215,230],stats_size_16:230,stats_size_32:[215,230],stats_size_64:230,stats_size_init_parm:[215,230],statu:[10,11,20,142,177,229,247,260,262,264,266,274,285,295,296,298],stdarg:[233,236],stderr:204,stdio:286,stener:217,step:[2,4,6,7,12,47,55,57,59,80,82,95,99,100,134,136,194,214,229,230,252,254,256,257,264,265,266,269,270,271,272,273,274,278,279,285,286,295,296,298],sterli:280,sterlinghugh:280,stic:[261,263],still:[5,59,66,84,102,103,249,260,294,299],stitch:1,stksz:[77,285,295,298],stkuse:[77,285,295,298],stlink:270,stm32:[270,272,298],stm32_boot:298,stm32_slinki:298,stm32f2x:270,stm32f303vc:[242,248],stm32f3discoveri:242,stm32f4:[140,141,142,267],stm32f4_adc_dev_init:140,stm32f4_hal_spi_cfg:[141,142],stm32f4disc_blinki:270,stm32f4disc_boot:270,stm32f4discoveri:[53,270],stm32f4discovery_debug:270,stm32f4x:270,stm32f4xx:193,stm32f4xxi:193,stm32serial:298,stm32x:270,stm34f4xx:193,stm:298,stmf303:242,stmf32f4xx:193,stmf3:242,stmf3_blinki:[242,248],stmf3_boot:[242,248],stop:[2,27,84,85,146,156,194,195,254,259,278,288],storag:[20,135,146,173,257,279],store:[1,11,22,27,31,34,35,37,50,55,57,59,61,80,86,88,90,106,135,136,146,153,185,202,205,206,224,230,256,259,261,262,279,285,286,287,292,294],stori:90,str:[136,200,206],straight:[259,285],straightforward:[256,286],strategi:251,strcmp:[135,285],stream:[21,206,211,212,224],strength:29,strict:[261,266],strictli:[179,180,185,286],string:[1,10,27,29,34,35,37,38,39,40,41,42,43,44,45,46,47,48,49,50,51,52,53,54,57,58,59,62,64,65,66,67,68,69,70,71,72,73,74,75,76,77,80,81,82,107,135,136,139,145,166,177,204,205,206,211,221,222,226,230,232,233,236,253,264,265,277,279,280,284,285,286,296],strip:[46,90],strlen:[259,261],strongli:158,struct:[84,85,87,88,90,91,92,94,95,99,103,104,105,106,134,135,136,140,141,142,146,147,148,149,150,151,152,153,154,155,156,159,160,161,162,163,164,166,167,169,170,171,172,174,175,176,179,182,183,185,186,192,194,197,199,204,205,206,207,208,209,210,211,212,213,214,215,217,218,221,222,223,224,225,226,227,228,230,233,238,239,246,251,253,259,261,262,263,264,265,268,277,284,285,286,290,292],structur:[7,11,12,18,28,55,61,78,95,99,105,134,136,140,142,152,168,181,184,194,199,204,205,212,214,215,216,222,226,227,230,253,254,261,267,277,278,285,286,290,294,297,302],strutur:90,stub:[61,107,212,246,253,264,265,268,277,285,286],studio:[5,13],stuff:279,style:[136,252],sub:[28,43,45,50,70,71,72,75,76,140,161,265,282],subcmd1:227,subcmd2:227,subcommand:[45,50,62,64,66,70,71,72,75,76,227],subcompon:21,subdirectori:[2,238,253,277],subfold:269,subject:185,submit:11,subrang:20,subscrib:[28,260,262,286],subsequ:[21,22,134,166,167,229,253,259,262,277],subset:[22,182,213,215,218,288],substitut:[6,252,256,257],subsystem:[30,59,88,135,136,141,142,221],subtract:[104,106],subtre:135,succe:[182,253,277],succesfulli:[247,248,249,250,254,256,257,260,266,268,269,270,271,272,273,274,278,285,288,292,295,298,299,300],success:[3,20,55,84,90,95,142,147,148,149,150,151,152,154,155,156,158,159,160,162,163,165,166,167,169,170,171,172,173,174,175,176,177,178,182,183,184,185,204,207,208,209,210,211,222,224,225,226,236,239,240,242,248,253,261,263,272,274,277,286],successfuli:[99,253,277,292],successfulli:[7,20,55,99,103,229,242,243,247,248,254,256,257,260,262,264,265,266,269,270,271,272,273,274,278,285,286,287,288,289,292,295,296,298],sudo:[4,6,7,11,57,58,60,80,83,257],suffici:[91,185],suffix:[253,277],suggest:[3,6,218,241,244,275,302],suit:[6,55,235,237,238,256,276],suitabl:[20,99,179],sum:90,summar:[99,229],summari:[6,11,19,36,221,226,265],supersed:185,supervision_timeout:[30,260],supplement:[29,259],supplementari:99,suppli:[158,176,178,182,253,277],support:[1,3,4,6,7,10,12,14,19,20,21,22,29,30,32,53,58,66,81,87,95,99,101,107,134,136,138,139,140,141,142,157,185,188,189,193,197,206,212,213,214,215,218,221,222,226,227,229,230,232,246,247,254,256,257,258,259,263,264,266,267,269,278,279,280,285,289,294,296,297,302],suppos:[43,94,103,104,193,230],suppress:296,suppresstasknam:12,sure:[2,7,8,57,90,205,253,256,257,259,261,266,268,274,277,279,284,285,286],suspend:288,svc:263,sw_rev:288,swap:[2,84,86,99,179,186,229,249,266,299],swclk:266,swd:[254,266,269,270,271,272,273,274,278,286,292],swdio:266,sweep:185,swim:270,swo:[254,269,278,292],symbol:[4,7,12,61,229,249,250,266,270,292,299,300],symlink:[60,83],sync:[20,25,39,57,58,59],sync_cb:[26,264,265],synchron:[20,39,49,57,58,59,102,104,140,197],syntax:[232,244,252,274,275,288],synthes:24,sys:[1,7,55,57,61,135,136,137,186,212,221,230,231,232,239,243,246,250,253,254,256,268,277,278,285,286,288,292,300],sys_config:[135,229],sys_config_test:7,sys_console_ful:229,sys_einv:[215,292],sys_enodev:215,sys_flash_map:[270,272],sys_log:229,sys_mfg:[7,266,269,270,271,272,288,295,298],sys_shel:229,sys_stat:229,sys_sysinit:[7,266,269,270,271,272,273,288,295,298],syscfg:[23,24,32,37,38,50,61,99,103,135,136,158,179,214,215,216,218,219,220,221,222,226,230,231,243,244,247,249,250,253,254,257,266,268,269,274,275,277,278,285,286,288,289,291,292,299,300],sysconfig:243,sysflash:[266,272],sysinit:[7,25,26,95,105,136,203,214,232,246,253,254,264,265,266,268,274,277,278,285,286,292],sysinit_assert_act:232,sysinit_panic_assert:[214,215,232],sysresetreq:266,system:[1,3,6,8,9,25,39,50,57,58,59,61,62,84,87,90,93,95,99,102,103,105,106,107,134,135,136,137,146,160,161,162,166,167,168,170,171,173,179,181,182,183,185,193,196,197,198,202,203,212,226,229,230,240,241,244,250,251,254,256,257,266,268,269,272,274,275,278,279,280,285,292,300],system_l:193,system_stm32f4xx:[270,272],systemview:302,sysview:[250,300,301],sysview_mynewt:[250,300],sytem:195,syuu:59,t_arg:84,t_ctx_sw_cnt:84,t_dev:213,t_driver:213,t_flag:84,t_func:[84,251],t_interfa:213,t_itf:213,t_lockcnt:84,t_name:84,t_next_wakeup:84,t_obj:84,t_pad:84,t_poll_r:213,t_prio:[84,86],t_run_tim:84,t_sanity_check:84,t_stackptr:84,t_stacksiz:84,t_stacktop:84,t_state:84,t_string:211,t_taskid:84,t_type_m:213,t_uinteg:211,tab:[30,36],tabl:[19,20,99,134,137,157,166,185,232,261,263,274,288],tag:280,tail:185,tailq_entri:[84,85,185,199],tailq_head:[84,185],take:[6,7,23,45,50,55,62,90,95,135,147,205,218,229,230,251,253,259,261,262,263,264,265,277,284,286],taken:[7,61,95,261,279,280,284],talk:[257,259,296],tap:[4,56,79],tar:[4,57,58,59,60,81,82,83],tarbal:4,target:[3,4,5,7,12,25,29,32,34,35,36,37,38,39,42,43,46,47,48,53,55,57,58,59,62,64,65,66,67,68,69,70,71,72,73,74,75,76,77,80,81,82,102,135,202,229,230,231,232,238,244,247,251,253,255,264,265,267,275,277,285,287,289,291,297],target_nam:34,targetin:[264,265],task1:[95,103,295,298],task1_evq:103,task1_handl:95,task1_init:95,task1_prio:95,task1_sanity_checkin_itvl:103,task1_sem:95,task1_stack:95,task1_stack_s:95,task2:[95,295,298],task2_handl:95,task2_init:95,task2_prio:95,task2_sem:95,task2_stack:95,task2_stack_s:95,task:[9,11,55,64,77,80,81,82,85,86,88,91,92,94,95,96,97,99,101,102,104,106,136,140,145,175,209,218,221,223,226,232,240,243,261,268,274,284,285,287,290,292,295,296,298,302],task_l:246,task_prior:[231,232],tasknam:12,taskstat:[64,78,80,81,82,137,139,243,295,298],tbd:[263,286],tc_case_fail_arg:238,tc_case_fail_cb:238,tc_case_init_arg:238,tc_case_init_cb:238,tc_case_pass_arg:238,tc_case_pass_cb:238,tc_print_result:[238,239],tc_restart_arg:238,tc_restart_cb:238,tc_suite_init_arg:238,tc_suite_init_cb:238,tc_system_assert:238,tck:266,tcp:[266,270],tdi:266,tdo:266,teach:251,team:[4,187,252],technic:[10,242],technolog:[21,141],tee:[1,34,35,37,38,39,40,41,42,43,44,45,46,47,48,49,50,51,52,53,54,57,58,59,62,285],telee02:274,telee02_boot:274,telemetri:264,telenor:274,teli:[264,265],tell:[30,55,146,161,202,206,229,230,232,242,259,261,264,265,272,280,284,286],telnet:[249,254,278,292,299],tem:288,temperatur:[165,213,288],templat:[7,45,253,256,277,285,292],temporari:[20,103,134,185],temporarili:[94,103],term:[3,134,140,158,193,196,279],termin:[2,4,7,8,10,12,20,21,27,59,82,136,160,161,162,166,167,170,177,179,180,182,185,249,254,257,259,262,263,266,268,269,270,271,272,273,274,278,290,292,299],terminato:162,termintor:162,terribl:[7,256],test:[4,6,12,39,50,57,58,59,61,64,67,71,75,80,81,82,134,136,137,187,215,216,229,232,233,234,235,236,237,238,239,240,243,247,249,257,263,264,265,266,268,269,271,276,279,284,286,296,299,302],test_assert:[234,235,237,253,277],test_assert_fat:[233,253,277],test_cas:[233,253,277],test_case_1:235,test_case_2:235,test_case_3:235,test_case_nam:[234,235],test_datetime_parse_simpl:[253,277],test_datetime_suit:[253,277],test_json:[253,277],test_json_util:[253,277],test_project:44,test_suit:[234,235,253,277],test_suite_nam:237,testbench:[7,61],testcas:[7,253,277],testnam:75,testutil:[7,186,253,277],text:[39,48,69,90,136,177,221,229,236,270,295,298],textual:1,tgt:135,tgz:4,than:[3,7,14,20,29,72,90,93,94,95,99,102,104,105,106,107,134,138,158,169,172,185,201,218,221,229,231,233,235,249,251,257,263,264,265,269,286,292,299],thank:30,thee:102,thei:[1,6,20,29,30,61,85,90,91,95,99,104,105,134,135,140,175,185,199,229,230,232,238,241,244,248,253,259,260,261,263,264,265,274,275,277,279,280,282,284,288],their_key_dist:27,them:[2,9,55,90,93,99,104,166,183,185,202,229,230,232,251,253,254,257,259,264,265,266,277,278,279,286,287,302],themselv:[93,95,263],theori:[55,232],therebi:[104,146],therefor:[20,134,154,158,166,251,281],thi:[1,2,3,4,5,6,7,8,9,10,11,12,14,18,20,21,22,23,24,25,26,27,29,30,31,32,33,34,41,43,52,53,55,57,58,59,60,61,63,64,66,71,72,80,81,82,83,84,85,86,88,89,90,91,92,93,94,95,96,97,99,100,101,102,103,104,105,107,134,135,136,138,140,141,142,143,144,146,147,148,149,152,158,160,161,162,164,165,166,167,168,170,172,174,175,177,178,179,180,181,182,184,185,186,187,189,190,192,193,194,195,197,199,200,201,202,203,206,207,208,209,210,211,212,213,214,215,216,217,218,219,221,222,223,224,226,228,229,230,231,232,234,235,236,237,238,239,240,241,242,243,244,246,247,248,249,250,251,252,253,254,255,256,257,258,259,260,261,262,263,264,265,266,267,268,269,270,271,272,273,274,275,277,278,279,280,281,284,285,286,287,288,289,290,291,292,294,295,296,297,298,299,300,302],thing:[1,10,21,24,26,55,61,91,99,102,103,140,213,229,253,264,265,277,280,284,285,286,290,292],thingi:[214,249,250,299,300],thingy_boot:292,thingy_debug:[249,250,292,299,300],thingy_my_sensor:292,think:[10,134,286],third:[6,19,254,257,259,266,278,286],thorough:280,those:[1,31,32,39,55,57,58,59,61,99,102,134,143,147,229,241,280,284,285,286],though:[93,134,185,194,218,229],thought:286,thread:[9,256,266,270,272],three:[2,11,19,59,61,93,134,136,172,212,229,230,232,246,251,256,258,259,265,266,272,274],through:[21,23,61,62,93,134,139,146,152,157,160,161,162,167,170,179,180,187,197,206,218,243,253,254,258,260,262,265,266,268,272,277,278,284,285,286,289,291,294],throughout:[1,99,253,277],throughput:21,thrown:6,thu:[90,99,104,134,140,179,180,193,194,251],tick:[84,85,96,97,102,103,106,136,196,199,221,251,268,269,285,292],ticker:85,ticket:10,tickl:[103,201],tid:[77,285,295,298],tie:229,tied:158,ties:256,time:[1,7,9,10,11,12,19,20,21,22,25,27,31,34,43,57,58,59,60,61,77,82,83,85,88,90,95,96,97,99,102,103,104,134,136,142,146,157,166,167,185,187,213,221,229,230,241,246,248,249,251,253,254,256,259,261,263,264,265,269,271,274,277,278,284,285,286,288,292,294,299],time_datetim:[229,292],time_datetime_test:[253,277],time_in_flight:90,timeout:[20,27,64,65,66,67,68,69,70,71,72,73,74,75,76,77,80,81,82,247,285],timer:[24,84,85,87,88,99,103,187,196,199,201,218,292],timer_0:24,timer_4:274,timer_5:24,timer_ev_cb:[268,292],timer_interrupt_task:246,timestamp:[72,213],timev:106,timezon:[106,253,277],timtest:[7,61],ting:[264,265],tini:[272,298],tinycbor:[7,287],tinycrypt:7,tinyprintf:107,tip:103,titl:[8,297],tlm:264,tlv:[27,134],tmp:[57,59,80,82,175,229],tmpstr:292,todo:[61,185,264,265],togeth:[1,43,55,61,90,93,143,185,229,260,272,286],toggl:[7,105,193,246,251,268],token:[75,95,104,221,281],told:202,too:[20,95,140,166,167,185,231,285],took:270,tool:[1,2,3,5,6,7,9,10,12,13,39,54,57,58,61,62,63,66,78,79,80,81,91,95,99,100,102,139,140,230,231,232,238,242,243,244,246,247,249,250,253,254,255,256,257,266,267,272,274,275,277,278,279,280,281,286,287,292,294,296,297,299,300,302],toolbox:2,toolchain:[2,3,5,7,12,33,59,63,243,247,254,257,267,278,294,297,302],toolkit:3,tools_1:[57,58,59,81,82],top:[1,10,12,35,61,93,140,179,231,253,257,264,265,277,286],topic:1,total:[9,55,64,65,66,67,68,69,70,71,72,73,74,75,76,77,80,81,82,90,107,134,185,269,271,274,286],tour:258,track:[19,21,22,134,185],tradeoff:229,trail:134,trailer:134,transact:[20,194],transfer:[22,197,285],transform:185,transit:134,translat:[193,264],transmiss:[20,27,197,225,274],transmit:[29,31,136,194,274],transmitt:200,transport:[20,21,27,80,136,139,232,247,256,257,266,270,285,286,287,289,291,294],travers:[90,160,161,162,167,170],traverse_dir:[160,161,162,167,170],treat:[146,207],tree:[1,6,7,50,55,61,99,165,256],tri:[3,64,65,66,67,68,69,70,71,72,73,74,75,76,77,80,81,82,135,142,231,274],trial:99,tricki:105,trigger:[6,10,88],triplet:213,troubleshoot:[230,231],truncat:[163,175,176,178],truncate_test:[253,277],trust:[22,27,285],tt_chr_f:263,tt_svc_type_p:263,ttl:[257,298],tty:[8,254,268,278,285,288,295,298],ttys002:66,ttys003:66,ttys005:296,ttys012:[295,298],ttys10:8,ttys2:[8,254,268,278,288,295,298],ttys5:8,ttyusb0:[10,66,257],ttyusb2:[8,254,278,295,298],ttyusb:[8,254,268,278,288,295,298],tu_any_fail:[239,253,277],tu_case_init_fn_t:238,tu_case_report_fn_t:238,tu_config:[238,239],tu_init:238,tu_restart_fn_t:238,tu_suite_init_fn_t:238,tupl:106,turn:[24,140,187,193,229,243,256,257,267,268,271,279,280,288,295],tutiori:[73,76],tutori:[2,3,6,7,8,10,12,21,23,59,77,214,215,219,220,221,238,242,243,246,247,251,253,254,255,256,257,258,259,260,261,262,263,264,265,266,268,269,270,271,272,273,274,277,278,284,285,286,287,288,289,290,291,292,295,296,298],tv_sec:[84,106,253,277,292],tv_usec:[84,106,253,277,292],tvp:[84,106],tweak:157,two:[2,3,10,12,18,19,21,22,23,27,31,43,45,50,55,61,66,90,91,94,95,99,101,105,106,134,136,138,179,185,194,212,213,221,227,229,230,231,232,242,243,246,251,253,254,256,257,259,261,264,265,266,268,269,270,271,272,273,274,277,278,279,280,281,282,285,286,287,288,291,292,295,298],tx_data:285,tx_len:285,tx_off:285,tx_phys_mask:27,tx_power_level:[27,29],tx_time_on_air:274,txd:274,txpower:274,txt:[70,159,163,166,169,176,177,178,250,300],type:[1,7,8,10,12,19,20,23,27,29,30,31,39,43,45,46,53,55,57,58,59,61,66,85,90,91,99,102,105,134,136,139,166,167,182,183,185,197,206,207,211,212,214,217,219,221,224,231,232,233,234,235,236,237,242,246,247,249,250,251,253,254,256,257,259,260,261,262,263,264,266,269,270,271,272,274,277,278,279,280,281,284,285,286,290,291,292,295,296,298,299,300],typedef:[26,84,88,136,156,206,213,221],typic:[3,9,21,26,31,55,61,90,92,95,99,100,103,134,136,140,179,180,187,190,193,194,197,212,213,229,230,232,238,253,259,264,265,277],tz_dsttime:[84,106,253,277],tz_minuteswest:[84,106,253,277],u8_len:142,uart0:[136,285,296],uart1:285,uart:[7,8,21,55,102,136,140,195,200,224,243,249,256,257,269,270,271,272,273,274,285,292,299],uart_0_pin_rx:285,uart_0_pin_tx:285,uart_bitbang:[195,269],uart_flow_control_non:136,uart_hal:[7,270,271,272],uartno:285,ubuntu:[4,6,7,57,80],uci:23,udev:270,udp:66,uext:298,uicr:23,uid:264,uint16:[27,28],uint16_max:27,uint16_t:[20,84,90,94,103,104,134,141,146,147,185,194,206,213,224,230,261,284,285,286],uint32:[27,71],uint32_max:27,uint32_t:[84,85,87,91,92,134,141,146,154,158,159,163,164,166,168,169,174,177,178,180,181,185,196,197,199,201,212,213,215,230],uint64:27,uint64_t:206,uint8:27,uint8_max:27,uint8_t:[23,32,84,88,90,94,99,103,134,136,140,141,146,154,158,159,160,161,162,166,167,168,169,170,174,177,180,185,192,194,197,206,212,213,215,224,230,259,261,264,265,285,286],uint_max:211,uinteg:[206,211],ultim:261,umbrella:229,unabl:[2,185,266,269,270,273],unaccept:20,unadorn:20,unam:2,unc_t:221,unchang:[99,185],unconfirm:274,und:[27,30],undefin:[82,232],under:[4,7,10,11,12,20,26,34,55,61,71,107,135,140,221,263,266,270,271,273,285,286],underli:[102,140,146,158,166,167,186,187,213],underlin:252,understand:[7,106,213,229,241,242,247,274,279,286],understood:[166,233],underwai:134,undesir:95,undirect:[27,259],unexpect:[20,160,161,162,167,170,173],unexpectedli:[20,253,277],unexpir:85,unicast:31,unicod:157,unidirect:27,unifi:140,uniform:[29,59],uniformli:62,uninstal:7,unint32:71,uninterpret:232,union:[185,206,261],uniqu:[9,19,32,99,185,212,230,231,232,264,274],unit:[1,7,20,27,39,51,57,58,59,85,105,134,232,253,277,302],unittest:[7,45,55,61,232,253,256,277,285],univers:200,unix:[2,59,158,242],unknown:[20,231],unlabel:285,unless:[27,105,134,179,202,232,285,286],unlicens:21,unlik:[20,91,253,277],unlink:[58,60,81,83,159,167,172,175],unlink_test:[253,277],unlock:[213,218],unmet:99,unpack:[57,59],unplug:273,unpredict:167,unprovis:31,unregist:217,unresolv:[187,253,277],unrespons:20,unset:[50,134],unsign:[105,206,230,273,292],unspecifi:[20,42],unstabl:[57,58,80,81],unsupport:[20,263],unsur:185,unsync:26,untar:4,until:[20,26,61,84,92,95,104,136,146,185,197,200,259,264,265,274,279],unuesd:262,unus:[71,90,284,285,286],unwritten:134,updat:[2,4,15,20,27,30,36,37,49,52,57,58,59,60,80,81,83,134,148,185,232,244,253,260,262,268,269,275,277,284,286,287,292],upgrad:[2,39,56,59,79,99,134,136,242,243,249,254,257,266,278,299,302],uplink:274,uplink_cntr:274,uplink_freq:274,upload:[10,43,70,71,158,202,229,247,269],upon:[1,3,10,26,55,134,185,230,262],upper:[23,185,232],uppercas:216,upstream:138,uri:[27,29,139],url:[27,264,277,279],url_bodi:264,url_body_len:264,url_schem:264,url_suffix:264,usabl:[1,99,256,264],usag:[1,9,57,58,59,62,80,81,82,90,140,141,158,179,185,194,213,221,226,230,232,251,274,285,296],usart6_rx:298,usart6_tx:298,usb:[2,3,8,21,42,66,243,246,247,251,254,257,266,267,269,270,271,272,273,274,278,286,288,294,295,297,298],usbmodem14211:66,usbmodem14221:66,usbmodem401322:8,usbseri:[8,254,268,278,285,288,295,298],usbttlseri:257,use:[1,4,5,6,7,8,11,12,14,19,20,21,22,24,27,30,32,41,45,50,51,55,56,58,59,61,64,65,66,67,68,69,70,71,72,73,74,75,76,77,79,81,82,85,87,88,92,93,99,100,102,104,105,134,135,136,137,140,142,146,147,157,158,171,172,175,179,182,183,185,186,194,206,207,208,209,210,211,212,213,214,215,216,217,218,221,222,223,226,227,229,230,231,232,238,242,243,244,245,246,247,248,249,250,251,253,254,255,256,257,259,260,261,262,264,265,266,267,268,269,272,274,275,277,278,280,281,284,285,286,287,288,291,292,294,295,296,297,298,299,300],use_wl:27,use_wl_inita:27,usec:[84,288,292],used:[6,7,10,11,12,19,20,22,23,24,27,29,30,31,34,46,49,61,66,72,84,87,90,91,93,94,99,104,105,106,107,134,135,136,141,142,146,149,157,158,162,185,191,194,195,196,197,199,201,206,213,214,215,221,229,230,231,232,233,234,235,236,237,240,241,242,248,251,253,254,257,259,261,262,263,264,265,266,274,277,278,279,280,286,287,288],useful:[3,20,95,177,215,256,279],user:[1,2,4,6,7,8,9,18,20,22,24,48,55,58,59,61,78,80,81,82,85,90,91,93,99,100,103,134,136,137,140,141,146,152,158,179,197,198,199,200,220,229,230,231,232,239,242,246,254,263,266,272,274,278,279,280,281,285,286,292,298],user_defined_head:90,user_hdr:90,user_id:[231,232],user_manu:242,usernam:[10,48,59,279],uses:[2,4,6,7,8,12,14,20,21,22,23,24,30,32,55,65,66,67,68,69,70,71,72,73,74,75,76,77,78,87,88,99,103,106,107,134,136,137,138,139,140,142,146,157,158,185,187,193,194,212,213,214,215,217,218,221,223,227,231,232,238,240,243,246,247,254,261,262,263,266,268,271,278,279,281,285,287,288,289,292,295,298],using:[1,2,4,6,7,8,11,12,19,20,21,24,26,27,28,29,31,33,36,37,43,44,57,58,59,60,61,63,66,76,80,81,82,83,85,87,90,93,94,95,100,101,102,103,104,105,106,107,134,135,140,146,149,151,156,157,158,166,185,187,193,194,196,201,206,215,216,218,221,229,230,232,234,235,237,238,242,243,246,247,249,250,251,252,253,254,256,257,263,265,266,267,268,269,270,271,272,273,274,277,278,284,285,286,287,289,292,296,297,299,300],usr:[4,6,11,36,57,58,59,60,80,81,82,83],usu:101,usual:[24,90,91,107,140,210,212],utc:[68,106,253,277],utctim:84,utf:29,util:[7,11,20,21,31,95,107,136,157,158,195,212,232,243,253,277],util_cbmem:292,util_cbmem_test:7,util_crc:[292,296,298],util_mem:[7,254,266,268,269,270,271,272,273,274,278,288,292,295,296,298],util_pars:[274,288,292],uuid128:[27,29,261,263,265],uuid128_is_complet:[27,29],uuid16:[27,28,29,261,284,286],uuid16_is_complet:[27,29],uuid32:[27,29],uuid32_is_complet:[27,29],uuid:[27,28,29,30,32,66,261,263,265,284,286,287],uvp:[84,106],v10:292,v14:270,v25:270,va_arg:215,va_list:[233,236],val:[23,24,39,50,57,58,59,61,99,135,190,207,212,230,231,232,243,264,265,268,274,285,287],valid:[20,39,50,53,57,58,59,61,66,72,90,91,134,141,146,156,158,175,182,183,185,194,213,253,261,277,285,286],valu:[1,4,7,12,20,23,24,27,28,29,30,37,39,42,46,50,53,57,58,59,61,62,64,65,66,68,71,72,75,80,81,82,84,86,90,99,104,105,106,134,135,140,180,181,185,194,206,212,214,216,218,221,229,230,243,244,246,247,249,257,260,261,262,263,264,265,275,279,280,284,285,286,288,289,291,292,294,299],valuabl:279,value1:[50,232],value2:[50,232],valuen:232,vanilla:157,vari:[9,90,102,134],variabl:[1,4,11,24,34,37,50,59,61,62,65,84,90,91,105,135,136,179,206,212,213,214,215,218,226,229,233,236,242,251,259,261,274,279,280,287,288,289,292],variant:[22,101,193],variat:12,varieti:[4,262],variou:[23,24,61,90,134,138,140,187,262,267,274],vdd:286,vector:288,vendor:279,ver:[1,7,55,204,205,242,254,257,266,278,279,280,281,285,286],ver_len:205,ver_str:205,verb:62,verbos:[1,7,34,35,37,38,39,40,41,42,43,44,45,46,47,48,49,50,51,52,53,54,57,58,59,62,254,266,278,285],veri:[1,9,31,55,90,105,107,134,185,214,249,252,255,263,268,269,279,286,287,299],verif:22,verifi:[22,57,59,80,82,134,185,187,215,229,247,251,253,269,270,271,273,274,277,286,287],versa:[8,229],version:[1,2,4,6,7,10,11,12,21,22,34,37,39,41,43,47,55,56,60,79,83,85,136,146,185,202,204,205,212,229,232,242,243,247,249,250,254,257,265,266,268,269,270,271,272,273,274,278,282,285,286,288,292,295,298,299,300],via:[8,20,26,42,55,134,136,140,158,160,161,162,167,170,179,180,182,185,186,187,194,218,221,229,230,232,247,257,258,259,261,269,271,274,279,285,286,288,289,291,294],vice:[8,229],vid:270,view:[1,7,10,12,30,50,62,66,216,220,221,229,230,232,250,279,286,291,300],vim:59,vin:288,violat:20,viper:11,virtual:[66,190,193],virtualbox:266,visibl:[2,28],visit:[39,57,58,59],visual:[5,13,250,300],visualstudio:12,vol:22,volatil:270,voltag:[140,142,187,270,286],volum:[29,157],vscode:12,vtref:[269,271,274,286],vvp:[84,106],wai:[2,3,9,21,30,31,59,61,85,88,95,105,106,136,158,193,194,195,212,229,231,252,279,280,281,285,286],wait:[84,86,88,94,95,104,105,142,197,232,246,251,272,274,284,285,286,294],waitin:94,wake:[86,92,95,104,105,218,251],wakeup:218,walk:[93,105,152,156,185,212,286],wall:6,wallclock:[85,106],wanda:81,want:[1,3,11,18,50,57,58,59,60,61,80,83,85,86,90,91,94,95,103,104,105,134,135,136,156,158,175,193,212,213,214,217,230,241,243,244,248,249,253,256,258,259,261,263,264,265,266,267,269,270,271,272,274,275,277,279,285,286,289,299,302],warn:[1,6,34,35,37,38,39,40,41,42,43,44,45,46,47,48,49,50,51,52,53,54,57,58,59,62,231,261,269,285],warranti:[4,249,250,266,285,286,292,299,300],watch:256,watchdog:[95,103,201],watchpoint:[266,270],wdog:67,wear:256,wear_level_test:[253,277],wearabl:9,web:[242,252],webfreak:12,websit:252,welcom:[8,140,255,278,285,288],well:[8,22,40,55,90,91,102,104,134,135,140,202,233,241,260,274,285,286],were:[29,73,84,90,134,187,229,280,284,285],werror:[6,50],wes:274,west:106,wfi:270,wget:[57,59,80,82],what:[7,8,20,41,55,102,104,141,146,179,180,185,214,215,229,232,245,251,253,259,262,263,264,265,277,280,284,285,286],whatev:[23,104,254,278],wheel:[8,242],when:[1,2,6,7,8,10,12,14,20,22,23,24,26,29,34,35,37,38,39,40,41,42,43,44,45,46,47,48,49,50,51,52,53,54,55,57,58,59,61,62,66,72,81,84,85,86,88,89,90,91,92,94,95,99,100,102,103,104,105,106,134,135,136,137,140,146,147,148,151,157,158,160,161,162,166,167,168,170,175,177,179,180,185,193,194,197,199,202,206,209,213,214,215,217,218,219,221,224,227,229,230,231,232,236,238,240,243,246,247,249,251,252,253,256,257,258,259,262,263,264,265,266,269,270,272,273,277,279,280,281,285,286,287,288,289,290,291,292,296,299],whenev:[21,26,140,185,206,217,261,263,292],where:[8,9,10,11,22,29,31,35,37,50,55,59,60,61,83,85,90,91,93,99,101,102,105,134,135,136,146,147,148,151,154,156,185,193,196,200,205,206,212,229,231,232,243,251,254,263,264,265,268,269,274,278,285,286,288,295,298],wherea:[90,280],whether:[10,12,22,84,88,106,134,146,161,194,198,214,215,216,218,219,220,221,230,232,240,253,259,261,263,277,288,290,291,292],which:[1,2,4,8,10,11,14,19,20,21,30,32,34,39,55,57,58,59,61,62,66,80,81,82,84,85,86,90,91,94,95,99,102,103,104,105,107,134,135,140,141,143,146,156,157,158,185,190,193,194,199,202,206,213,215,229,230,231,233,236,239,240,242,247,249,251,253,254,259,260,261,262,263,264,265,266,274,277,278,279,280,285,286,296,299],white:[22,27],whitelist:27,who:10,whole:141,whose:[61,62,185,218],why:[10,251],wide:[21,229],wifi:[7,254,278],wifi_connect:[254,278],wifi_init:278,wifi_request_scan:[254,278],wikipedia:[194,197],winc1500_wifi:[254,278],window:[5,6,7,9,12,27,56,66,78,79,99,136,247,249,254,257,266,268,269,270,271,272,273,274,278,288,295,298,299],winusb:[270,272,298],wipe:150,wire:[8,194,197,274,285,286,298],wireless:21,wish:[6,10,179,180,194,251,279,297],withdraw:10,within:[1,12,20,31,41,55,99,100,102,134,140,146,151,154,156,179,180,185,187,193,204,206,212,215,216,217,221,230,238,251,253,262,272,277,279,285],without:[6,10,22,24,28,30,134,158,167,179,180,185,186,212,221,228,229,230,232,247,253,266,277,285,286,290],wno:6,won:[8,229,286],wonder:286,word:[6,55,90,95,104,134,185,249,250,261,266,279,292,299,300],word_siz:197,work:[2,4,8,10,11,22,24,55,61,62,86,94,95,99,101,102,104,105,134,136,140,141,166,187,230,242,243,248,251,253,256,257,260,266,268,274,277,282,284,285,286,289,291,294],work_stack:251,work_stack_s:251,work_task:251,work_task_handl:251,work_task_prio:251,workaround:10,workspac:[1,2,11,39,57,58,59,60,80,82,83],workspaceroot:12,world:[12,21,200,259,264,265,267,281,302],worri:95,worth:[1,100,285],would:[5,12,58,59,81,82,85,90,95,104,134,136,143,146,187,193,194,209,227,229,230,238,251,253,256,272,274,277,279,280,285,286,294,298],wrap:[106,230,268],wrapper:88,write:[1,9,14,20,28,61,64,65,80,81,82,88,100,134,135,136,140,141,142,146,147,148,152,157,158,163,164,174,176,178,179,180,187,191,193,194,200,202,204,207,208,209,210,212,225,230,236,246,251,255,260,262,263,274,276,285,286,287,294],write_cmd_rx:[76,243],write_cmd_tx:[76,243],write_config:[163,176],write_id:178,write_req_rx:[76,243],write_req_tx:[76,243],write_rsp_rx:[76,243],write_rsp_tx:[76,243],written:[11,20,23,59,82,95,134,146,147,148,151,156,162,163,166,169,175,176,177,179,180,185,261,263,268,280],wrong:[42,286],wsl:[12,59],www:[107,242,249,250,257,266,285,286,292,298,299,300],x86:[4,12],x86_64:[249,250,266,292,299,300],xml:[7,85,88,90,91,92,93,94,103,104,135],xpf:4,xpsr:[266,270,272],xtal_32768:99,xtal_32768_synth:24,xxx:[6,99,141],xxx_branch_0_8_0:[279,280],xxx_branch_1_0_0:[279,280],xxx_branch_1_0_2:[279,280],xxx_branch_1_1_0:[279,280],xxx_branch_1_1_2:[279,280],xxx_branch_1_2_0:[279,280],xxx_branch_1_2_1:[279,280],xxxx:187,xzf:[57,59,60,82,83],yai:285,yaml:11,year:31,yes:[22,274],yesno:27,yet:[7,84,95,102,247,256,279,280,286],yield:95,yml:[1,6,7,41,43,50,52,53,55,61,100,101,107,135,136,141,142,158,179,186,212,214,221,229,230,231,232,242,243,244,246,253,254,256,257,266,268,274,275,277,278,279,281,282,285,286,287,288,292],you:[1,3,4,5,6,7,8,9,10,11,12,18,19,30,33,34,35,39,41,43,45,46,47,50,51,52,53,54,55,57,58,59,60,61,63,64,66,68,76,80,81,82,83,85,88,95,99,100,101,102,107,134,135,136,137,138,140,143,144,146,147,148,152,161,166,167,169,175,177,179,180,186,187,190,193,194,196,206,209,212,213,214,216,217,218,221,222,223,226,227,228,229,230,231,232,238,241,243,244,246,247,249,250,251,252,253,254,255,256,257,258,259,260,261,262,263,264,265,266,267,268,269,270,271,272,273,274,275,277,278,279,280,281,284,286,287,288,289,290,291,292,294,295,296,297,298,299,300,302],your:[1,3,4,6,8,10,19,30,39,50,52,55,56,58,59,60,61,70,71,79,81,82,83,85,95,99,100,101,102,103,105,137,138,139,140,141,142,144,146,157,179,187,212,214,221,227,229,231,232,238,244,246,247,248,249,250,252,255,256,257,258,259,260,262,263,264,265,267,268,274,275,280,284,285,286,287,289,290,294,295,297,298,299,300,302],yourself:[2,10,30,95,99,258,285,302],ype:[264,265],yym:6,zadig:[270,272,298],zero:[12,24,90,99,106,150,154,156,163,175,176,181,206,222,224,225,226,232,251,253,254,263,264,265,267,274,277,278,279,292,302],zip:[4,269,286]},titles:["&lt;no title&gt;","Concepts","Everything You Need in a Docker Container","Setup &amp; Get Started","Installing the Cross Tools for ARM","Native Installation","Installing Native Toolchain","Creating Your First Mynewt Project","Using the Serial Port with Mynewt OS","Mynewt Documentation","FAQ","Contributing to Newt or Newtmgr Tools","Developing Mynewt Applications with Visual Studio Code","Appendix","NimBLE Host ATT Client Reference","NimBLE Host GAP Reference","NimBLE Host GATT Client Reference","NimBLE Host GATT Server Reference","NimBLE Host","NimBLE Host Identity Reference","NimBLE Host Return Codes","BLE User Guide","NimBLE Security","Configure device ddress","Configure clock for controller","NimBLE Setup","Respond to <em>sync</em> and <em>reset</em> events","GAP API for btshell","GATT feature API for btshell","Advertisement Data Fields","API for btshell app","Bluetooth Mesh","Sample application","Mynewt Newt Tool Documentation","newt build","newt clean","newt complete","newt create-image","newt debug","newt help","newt info","newt install","newt load","newt mfg","newt new","newt pkg","newt resign-image","newt run","newt size","newt sync","newt target","newt test","newt upgrade","newt vals","newt version","Newt Tool Guide","Install","Installing Newt on Linux","Installing Newt on Mac OS","Installing Newt on Windows","Installing Previous Releases of Newt","Theory of Operations","Command Structure","Mynewt Newt Manager Documentation","Command List","newtmgr config","newtmgr conn","newtmgr crash","newtmgr datetime","newtmgr echo","newtmgr fs","newtmgr image","newtmgr log","newtmgr mpstat","newtmgr reset","newtmgr run","newtmgr stat","newtmgr taskstat","Newt Manager Guide","Install","Installing Newtmgr on Linux","Installing Newtmgr on Mac OS","Installing Newtmgr on Windows","Installing Previous Releases of Newtmgr","Core OS API","Callout","Scheduler","CPU Time","Event Queues","Heap","Mbufs","Memory Pools","Mqueue","Msys","Mutex","Mynewt Core OS","os_init","os_start","os_started","BSP Porting","Porting Mynewt to a new CPU Architecture","Porting Mynewt to a new MCU","Porting Mynewt OS","Sanity","Semaphore","Task","OS Time","Baselibc","&lt;no title&gt;","&lt;no title&gt;","&lt;no title&gt;","&lt;no title&gt;","&lt;no title&gt;","&lt;no title&gt;","&lt;no title&gt;","&lt;no title&gt;","&lt;no title&gt;","&lt;no title&gt;","&lt;no title&gt;","&lt;no title&gt;","&lt;no title&gt;","&lt;no title&gt;","&lt;no title&gt;","&lt;no title&gt;","&lt;no title&gt;","&lt;no title&gt;","&lt;no title&gt;","&lt;no title&gt;","&lt;no title&gt;","&lt;no title&gt;","&lt;no title&gt;","&lt;no title&gt;","&lt;no title&gt;","&lt;no title&gt;","Bootloader","Config","Console","Customizing Newt Manager Usage with mgmt","Newt Manager","Using the OIC Framework","Drivers","flash","mmc","elua","lua_init","lua_main","Flash Circular Buffer (FCB)","fcb_append","fcb_append_finish","fcb_append_to_scratch","fcb_clear","fcb_getnext","fcb_init","fcb_is_empty","fcb_offset_last_n","fcb_rotate","fcb_walk","The FAT File System","File System Abstraction","fs_close","fs_closedir","fs_dirent_is_dir","fs_dirent_name","fs_filelen","fs_getpos","fs_mkdir","fs_open","fs_opendir","struct fs_ops","fs_read","fs_readdir","fs_register","fs_rename","fs/fs Return Codes","fs_seek","fs_unlink","fs_write","fsutil_read_file","fsutil_write_file","Newtron Flash Filesystem (nffs)","struct nffs_area_desc","struct nffs_config","nffs_detect","nffs_format","nffs_init","Internals of nffs","Other File Systems","Hardware Abstraction Layer","HAL Interfaces","hal_bsp","Creating New HAL Interfaces","hal_flash","hal_flash_int","hal_gpio","hal_i2c","Using HAL in Your Libraries","hal_os_tick","hal_spi","hal_system","hal_timer","hal_uart","hal_watchdog","Image Manager","imgmgr_module_init","imgr_ver_parse","imgr_ver_str","JSON","json_encode_object_entry","json_encode_object_finish","json_encode_object_key","json_encode_object_start","json_read_object","Logging","Sensor API","Creating and Configuring a Sensor Device","Sensor Device Driver","Mynewt Sensor Framework Overview","Sensor Listener API","Sensor Manager API","OIC Sensor Support","Sensor Shell Command","Shell","shell_cmd_register","shell_evq_set","shell_nlip_input_register","shell_nlip_output","shell_register","shell_register_app_cmd_handler","shell_register_default_module","Split Images","Statistics Module","Validation and Error Messages","System Configuration and Initialization","TEST_ASSERT","TEST_CASE","TEST_CASE_DECL","TEST_PASS","TEST_SUITE","testutil","tu_init","tu_restart","OS User Guide","Blinky, your \u201cHello World!\u201d, on STM32F303 Discovery","Enabling Newt Manager in Your Application","How to Reduce Application Code Size","How to Define a Target","How to Use Event Queues to Manage Multiple Events","Over-the-Air Image Upgrade","Pin Wheel Modifications to \u201cBlinky\u201d on STM32F3 Discovery","SEGGER RTT Console","SEGGER SystemView","Tasks and Priority Management","Try Markdown","Write a Test Suite for a Package","Enable Wi-Fi on Arduino MKR1000","Bluetooth Low Energy","Set up a bare bones NimBLE application","Use HCI access to NimBLE controller","BLE Peripheral Project","Advertising","BLE Peripheral App","Characteristic Access","GAP Event callbacks","Service Registration","BLE Eddystone","BLE iBeacon","Blinky, your \u201cHello World!\u201d, on Arduino Zero","Project Blinky","Enabling The Console and Shell for Blinky","Blinky, your \u201cHello World!\u201d, on Arduino Primo","Blinky, your \u201cHello World!\u201d, on STM32F4-Discovery","Blinky, your \u201cHello World!\u201d, on a nRF52 Development Kit","Blinky, your \u201cHello World!\u201d, on Olimex","Blinky, your \u201cHello World!\u201d, on RedBear Nano 2","LoRaWAN App","How to Reduce Application Code Size","Other","Write a Test Suite for a Package","Enable Wi-Fi on Arduino MKR1000","Adding Repositories to your Project","Create a Repo out of a Project","Accessing a private repository","Upgrade a repo","Air Quality Sensor Project","Air quality sensor project via Bluetooth","Air quality sensor project","Adding an Analog Sensor on nRF52","Adding OIC Sensor Support to the bleprph_oic Application","Enabling an Off-Board Sensor in an Existing Application","Enabling OIC Sensor Data Monitoring in the sensors_test Application","Changing the Default Configuration for a Sensor","Enabling OIC Sensor Data Monitoring","Developing an Application for an Onboard Sensor","Sensors","Sensor Tutorials Overview","Project Slinky using the Nordic nRF52 Board","Project Sim Slinky","Project Slinky","Project Slinky Using Olimex Board","SEGGER RTT Console","SEGGER SystemView","Tooling","Tutorials"],titleterms:{"abstract":[158,187],"default":[251,268,290],"function":[99,106,107,143,146,202,206,213,215,217,218,232,238,251,261,263,287,290],"import":242,"new":[7,44,100,101,185,190,260,290,292,295,296,298],"public":23,"return":[20,96,97,98,142,144,145,147,148,149,150,151,152,153,154,155,156,159,160,161,162,163,164,165,166,167,169,170,171,172,173,174,175,176,177,178,182,183,184,203,204,205,207,208,209,210,211,222,223,224,225,226,227,228,233,234,235,236,237,239,240],"switch":[107,251],"try":[252,253,277],Adding:[58,81,230,279,286,287,290,292],For:4,The:[157,268],Use:[2,243,246,257,268,285,292,295,298],Used:213,Uses:212,Using:[8,57,80,90,92,136,139,195,288,292,298],acceleromet:290,access:[257,261,281],adafruit:10,adc:286,add:[66,99,264,265,284,285,286,287,292],addit:[279,286],address:[19,23,30,264,265],administr:10,advertis:[27,29,30,259,264,265],air:[247,283,284,285],all:246,ambigu:231,analog:286,apach:[9,31],api:[27,28,30,84,85,86,87,88,89,90,91,92,93,94,103,104,135,136,157,158,179,186,190,212,213,217,218,292],app:[9,30,61,229,250,257,260,274,292,294,300],app_get_light:287,app_set_light:287,appendix:[13,99],applic:[7,12,32,95,212,213,214,229,242,243,244,246,251,254,256,257,264,265,266,268,269,270,271,272,273,274,275,278,286,287,288,289,290,292,295,298],apt:[57,80],architectur:100,arduino:[8,254,266,269,278],area:[179,185,231],argument:[96,97,98,144,145,147,148,149,150,151,152,153,154,155,156,159,160,161,162,163,164,165,166,167,169,170,171,172,174,175,176,177,178,182,183,203,204,205,207,208,209,210,211,222,223,224,225,226,228,233,234,235,236,237,239,240],arm:4,artifact:61,assert:[253,277],assign:231,associ:12,att:[14,20],attach:257,attribut:[30,263],autocomplet:36,avail:[27,28,39,43,50,267,279,294,297],bare:256,baselibc:107,bash:36,basic:95,beacon:[264,265],bearer:31,begin:[30,259],being:261,belong:30,between:[254,278],binari:[57,59,80,82],bit:6,ble:[21,256,258,260,264,265,286,287],blehci:257,bleprph_gap_ev:262,bleprph_oic:287,blink:242,blink_rigado:48,blinki:[7,193,242,248,266,267,268,269,270,271,272,273],block:185,bluetooth:[21,31,255,257,284],bluez:257,bno055:288,bno055_log:215,bno055_stat:215,board:[102,214,254,266,269,270,271,272,273,274,278,286,287,288,289,295,298],bone:256,boot:[134,229],bootload:[134,254,257,266,269,270,271,272,273,274,278,288,292,295,298],branch:[58,81],brew:6,bsp:[53,99,102,231],btmgmt:257,btmon:257,btshell:[27,28,30],buffer:146,bug:10,build:[7,9,12,34,55,61,242,243,248,251,254,256,257,266,268,269,270,271,272,273,274,278,286,287,288,289,290,292,295,296,298],cach:185,call:290,callback:262,callout:[85,246],can:10,cannot:290,categori:302,chang:[33,63,290],channel:27,characterist:[30,258,261],check:[57,58,59,80,81,82,99,103,134,218],choos:[253,277],circular:146,clean:35,clear:273,cli:[135,285],client:[14,16],clock:24,close:274,code:[10,12,20,99,100,173,230,244,253,275,277],collect:185,command:[12,27,28,39,43,50,62,64,66,138,215,220,221,243,257,285,296],committ:10,commun:[8,243,268],compil:100,complet:[36,221],compon:[21,279],comput:[57,80,254,278,288,292],concept:[1,229],conclus:[256,264,265,286],condit:232,config:[65,135],configur:[1,12,23,24,27,28,30,135,157,212,213,214,215,218,231,232,242,243,264,265,268,290],conflict:232,congratul:[253,277],conn:66,connect:[27,30,243,247,249,254,257,266,268,269,270,271,272,273,274,278,286,287,288,289,292,295,296,298,299],consider:251,consol:[136,221,230,249,254,268,278,288,292,299],contain:2,content:[33,63],context:251,contribut:11,control:[24,257,264,265,287,288,289,294],copi:[99,287],core:[20,84,95,102],cpu:[84,87,100,102],crash:67,creat:[7,37,90,99,100,190,214,242,243,247,253,254,256,257,260,264,265,266,269,270,271,272,273,274,277,278,280,285,286,287,288,289,292,295,296,298],creation:95,cross:4,crystal:24,current:229,custom:[103,137,243],data:[29,85,87,88,89,90,91,92,94,103,104,106,143,146,158,179,185,194,202,206,213,215,217,218,221,238,259,274,287,288,289,290,291,292],datetim:68,ddress:23,debian:[57,80],debug:[12,38,61,99],debugg:[4,12],declar:230,decod:206,defin:[12,99,215,230,245],definit:[189,191,192,193,194,196,197,198,199,200,201,231,232],delet:[66,287],depend:[7,61,99,102,141,142,186,187,242,243,268,280,287,292],descript:[34,35,37,38,40,41,42,43,44,45,46,47,48,49,50,51,52,53,65,66,67,68,69,70,71,72,73,74,75,76,77,85,86,87,88,89,91,94,102,103,104,105,106,107,136,140,143,146,157,158,179,187,189,191,192,193,194,196,197,198,199,200,201,202,206,221,229,238,288],descriptor:[30,258,263,279],design:[140,187],detail:230,detect:185,determin:261,develop:[12,271,292],devic:[2,23,27,30,135,213,214,215,247,257,287,288,289,290,294],direct:30,directori:[61,185],disabl:27,discov:30,discoveri:[27,242,248,270],disk:185,disk_op:158,displai:30,docker:2,document:[10,33,63],doe:279,download:[11,57,61,80,99,242,248,274,286],driver:[140,213,215,285,286,290],duplic:231,echo:69,eddyston:264,edit:10,editor:10,elua:143,empti:[264,265],emul:288,enabl:[2,27,36,221,229,230,243,254,268,278,287,288,289,291,292],encod:206,endif:[214,215],energi:255,enhanc:179,enter:256,environ:11,equip:251,eras:269,error:231,establish:[30,254,257,278],etap:286,event:[26,88,246,262,268],everyth:[2,274,286],exampl:[8,20,21,26,34,35,37,38,39,43,44,45,46,47,48,50,51,53,54,65,66,67,68,69,70,71,72,73,74,75,76,77,95,135,140,141,142,144,145,147,148,149,150,151,152,153,154,155,156,157,159,160,161,162,163,165,166,167,169,170,172,174,175,176,177,178,182,183,187,189,191,192,193,196,198,199,200,201,204,205,207,208,209,210,211,222,224,225,227,228,231,232,233,234,235,237,238,239,240,246],execut:[6,242,248,249,250,269,270,271,273,274,286,296,299,300],exist:[243,268,279,288],explor:7,express:231,extend:[27,292],extens:[2,12],extern:[242,254,266,278],faq:10,fat:157,fcb:146,fcb_append:147,fcb_append_finish:148,fcb_append_to_scratch:149,fcb_clear:150,fcb_getnext:151,fcb_init:152,fcb_is_empti:153,fcb_offset_last_n:154,fcb_rotat:155,fcb_walk:156,featur:[7,10,21,22,28,31,95],fetch:[7,254,266,278],field:29,file:[99,141,142,157,158,159,160,161,162,163,164,165,166,167,168,169,170,171,172,173,174,175,176,177,178,180,181,182,183,184,185,186,230,235,280,287,290,292],filesystem:[158,179],fill:99,find:279,first:[7,9],flag:[34,35,37,38,39,40,41,42,43,44,45,46,47,48,49,50,51,52,53,54,65,66,67,68,69,70,71,72,73,74,75,76,77],flash:[99,134,141,146,179,185,231,269,273],format:[134,185],framework:[139,215,216,243,291],from:[57,58,59,80,81,82,136,287,289,290],fs_close:159,fs_closedir:160,fs_dirent_is_dir:161,fs_dirent_nam:162,fs_filelen:163,fs_getpo:164,fs_mkdir:165,fs_op:168,fs_open:166,fs_opendir:167,fs_read:169,fs_readdir:170,fs_regist:171,fs_renam:172,fs_seek:174,fs_unlink:175,fs_write:176,fsutil_read_fil:177,fsutil_write_fil:178,ft232h:8,full:136,futur:179,gap:[15,27,262],garbag:185,gatt:[16,17,28,284],gcc:6,gdb:6,gener:[22,30,140,187,232,246],get:[3,57,80,215],git:[10,59],global:[34,35,37,38,39,40,41,42,43,44,45,46,47,48,49,50,51,52,53,54,65,66,67,68,69,70,71,72,73,74,75,76,77],guarante:262,guid:[21,55,78,241],hal:[102,188,190,195,285],hal_bsp:189,hal_flash:191,hal_flash_int:192,hal_gpio:193,hal_i2c:194,hal_os_tick:196,hal_spi:197,hal_system:198,hal_tim:199,hal_uart:200,hal_watchdog:201,handler:[135,212,221],hardcod:23,hardwar:[23,187,242,249,250,274,286,288,299,300],have:10,hci:[20,257],header:[14,15,16,17,19,20,90,141,142,158,159,160,161,162,163,164,165,166,167,168,169,170,171,172,173,174,175,176,177,178,180,181,182,183,184,186,230,287,290],heading3:252,heading4:252,heap:89,hello:[242,266,269,270,271,272,273],help:[39,221],high:134,hold:230,homebrew:[58,81],host:[14,15,16,17,18,19,20,264,265],how:[10,107,232,244,245,246,275,279,287,290],ibeacon:265,ident:19,identifi:279,ignor:231,imag:[10,37,46,71,134,202,229,242,243,247,248,254,257,269,270,271,272,273,274,278,286,287,288,289,290,292,295,298],imgmgr_module_init:203,imgr_ver_pars:204,imgr_ver_str:205,implement:[100,140,212,215,230],includ:[30,215,230,263],indefinit:[264,265],info:40,inform:221,initi:[30,141,142,179,213,215,230,232,251,290],inod:185,input:[136,221],instal:[2,4,5,6,11,12,36,41,56,57,58,59,60,79,80,81,82,83,242,274,286],instead:292,integr:134,interfac:[186,188,190,213],intern:[179,185],interrupt:246,introduct:[9,14,15,16,17,18,19,20,31,55,99,246,253,258,277],invalid:231,invok:138,issu:10,join:274,json:206,json_encode_object_entri:207,json_encode_object_finish:208,json_encode_object_kei:209,json_encode_object_start:210,json_read_object:211,kei:[22,27],kit:271,l2cap:[20,27],laptop:10,latest:[57,58,59,80,81,82],launch:[250,300],layer:187,led:[242,248],legaci:27,level:[134,212,247],libc:6,librari:[195,242],like:10,limit:134,line:221,link:4,linker:99,linux:[2,4,6,8,11,57,60,80,83],lis2dh12_onb:214,list:[10,64,107,143,146,202,206,213,217,218,229,238,252,264,265,288,292],listen:[217,292],load:[42,243,254,257,266,269,270,271,272,273,278,287,288,289,290,292,295,298],loader:229,log:[72,212,215,247],look:218,lorawan:274,low:255,lua_init:144,lua_main:145,mac:[2,4,6,8,11,58,60,81,83],macro:106,main:[251,268,287,290,292],make:10,manag:[9,10,20,55,63,78,137,138,202,218,243,246,251],manual:[57,80],map:[99,134],markdown:252,master:[58,81],mbuf:90,mcu:[99,101,102],measur:179,memori:[91,273],merg:10,mesh:[21,31],messag:231,method:[23,57,80],mfg:43,mgmt:137,mingw:59,minim:136,miscellan:179,mkr1000:[254,278],mmc:142,model:31,modif:248,modifi:[243,268,287,292],modul:[221,230],monitor:[257,289,291],more:[55,242],move:185,mpstat:73,mqueue:92,msy:93,msys2:59,multipl:[12,158,230,231,246],mutex:94,my_sensor_app:292,mynewt:[2,7,8,9,10,12,23,31,33,58,63,81,95,99,100,101,102,136,216,256,279,287,289,294],mynewt_v:[214,215],name:[30,221,230,232],nano:273,nativ:[5,6],need:[2,242,248,249,250,274,279,285,286,288,299,300],newt:[2,9,10,11,12,33,34,35,36,37,38,39,40,41,42,43,44,45,46,47,48,49,50,51,52,53,54,55,57,58,59,60,63,78,137,138,243],newtmgr:[11,65,66,67,68,69,70,71,72,73,74,75,76,77,80,81,82,83,138,221,230,243,247,295,296,298],newtron:179,next:[6,288],nff:[179,185],nffs_area_desc:180,nffs_config:181,nffs_detect:182,nffs_format:183,nffs_init:184,nimbl:[14,15,16,17,18,19,20,21,22,25,256,257,264,265],node:31,nordic:[8,295],normal:90,note:[55,96,97,106,143,144,145,147,148,149,150,151,152,153,154,155,156,159,162,164,165,166,167,171,172,174,176,177,180,181,203,204,205,223,230,233,236,286],notnul:231,nrf52:[271,286,288,295],nrf52_adc:286,nrf52dk:[8,10],nrf:23,object:[185,213,242,248,249,250,267,274,286,299,300],off:[214,288],oic:[139,219,287,289,291,294],oicmgr:243,olimex:[272,298],omgr_app_init:287,onboard:[214,292],onto:[254,266,278],open:[257,274],openocd:4,oper:[55,61,134,194,197,229],option:[243,269],orient:27,os_init:96,os_start:[97,98],ota:274,other:[7,12,186,243,276,280],out:[253,277,279,280],output:[48,53,136],over:[221,247],overrid:[231,232],overview:[64,216,258,259,260,262,267,287,290,291,294,297],own:10,pack:2,packag:[1,7,57,61,80,99,102,136,186,212,213,216,231,232,243,253,254,256,266,277,278,285,287,288,292],packet:90,passiv:30,patch:10,peer:[20,30],perform:30,peripher:[258,260],persist:135,pin:248,pkg:[45,99],platform:[8,187],poll:[213,218],pool:[90,91],port:[8,99,100,101,102,274],preempt:251,prerequisit:[7,243,246,247,251,254,257,260,266,267,268,269,270,271,272,273,278,287,288,289,290,291,292,294,295,296,297,298,302],preview:[33,63],previou:[60,83],primo:269,principl:[140,187],prioriti:[231,251],privaci:22,privat:281,pro:8,process:[221,268],produc:[6,61],profil:[243,247,296],project:[1,7,10,12,21,242,243,254,256,257,258,266,267,268,269,270,271,272,273,274,278,279,280,283,284,285,286,295,296,297,298],prompt:221,protect:273,protocol:[221,243,264,265],provis:31,pull:[2,10],put:246,qualiti:[283,284,285],queri:[295,298],question:10,queue:[88,246,268],ram:185,random:23,rate:213,rational:55,read:[30,213,215,261,290,292],reboot:290,rebuild:[11,292],reconfigur:214,recoveri:134,redbear:273,reduc:[10,244,247,275],refer:[14,15,16,17,19,20,232],referenc:232,regist:[103,186,215,218,221,230,288],registr:263,releas:[57,58,59,60,80,81,82,83],renam:185,repo:[279,280,282],repositori:[7,10,55,279,280,281,286],represent:185,request:10,requir:99,reset:[26,74,134],resign:46,resolut:280,resolv:[61,232,280],respond:26,restrict:231,retriev:[229,230],review:[251,261],round:248,rtt:[249,292,299],run:[7,12,47,75,249,250,266,268,296,299,300],runtim:[23,135],safeti:158,sampl:[32,288,290],saniti:103,satisfi:99,scale:[253,277],scan:30,schedul:[84,86],scratch:185,script:[2,99],section:230,secur:[20,22,27],segger:[4,249,250,299,300],select:2,semaphor:104,semiconductor:8,send:[30,257,274],sensor:[213,214,215,216,217,218,219,220,283,284,285,286,287,288,289,290,291,292,293,294],sensor_read:292,sensors_test:289,sequenc:229,serial:[8,221,254,257,268,278,295,298],server:17,servic:[30,258,263,284,286],set:[6,11,30,57,80,99,212,213,215,231,232,243,256,259,263,268,285,287,290,296],settl:24,setup:[3,8,25,249,250,254,278,299,300],shell:[215,220,221,268,292],shell_cmd_regist:222,shell_evq_set:223,shell_nlip_input_regist:224,shell_nlip_output:225,shell_regist:226,shell_register_app_cmd_handl:227,shell_register_default_modul:228,should:280,show:[30,66],sign:[134,242,254,269,270,271,272,273,274,278,286,295,298],signatur:261,sim:296,simul:7,singl:229,size:[10,48,244,275],skeleton:292,slinki:[295,296,297,298],slot:134,smart:[287,289,294],softwar:[10,250,300],some:10,sourc:[7,11,55,57,59,80,82,243,264,265,285,287],space:185,special:106,specif:[100,280],specifi:[186,232],split:229,stack:[251,264,265],start:[3,254,257,278],startup:99,stat:[76,215,230],state:[134,135,229],statist:230,statu:134,step:[11,247,267,287,288,289,290,292,297],stm32f303:242,stm32f3:[242,248],stm32f4:270,storag:27,struct:[158,168,180,181],structur:[62,85,87,88,89,90,91,92,94,103,104,106,143,146,158,179,185,202,206,213,217,218,221,238],stub:136,studio:12,stuff:285,sub:66,submit:10,suit:[253,277],summari:20,support:[2,31,61,102,158,187,216,219,242,243,287,288,291,292],swap:134,sync:[26,49,264,265],syscfg:[212,229,232,287],sysinit_app:232,system:[24,55,157,158,186,231,232],systemview:[250,300],tabl:230,talk:[254,278],tap:[58,81],target:[1,23,50,61,99,242,243,245,248,249,250,254,256,257,260,266,268,269,270,271,272,273,274,278,286,288,292,295,296,298,299,300],task:[12,84,103,105,231,246,251,286],taskstat:77,tcp:[254,278],templat:99,termin:288,test:[7,51,99,253,277,285],test_assert:233,test_cas:[234,235],test_case_decl:235,test_pass:236,test_suit:237,testutil:238,theori:[61,194,197,229],thingi:292,thread:158,through:230,time:[24,84,87,106],timer:[246,268],togeth:246,tool:[4,11,33,55,59,82,301],toolchain:[4,6],topolog:31,transport:[221,243],tree:285,tu_init:239,tu_restart:240,tutori:[229,267,294,297,302],type:[213,215,218,288],undefin:231,under:[253,277],undirect:30,unifi:229,unlink:185,updat:11,upgrad:[52,57,58,80,81,229,247,282],upload:268,usag:[34,35,36,37,38,39,40,41,42,43,44,45,46,47,48,49,50,51,52,53,54,65,66,67,68,69,70,71,72,73,74,75,76,77,137,146],usb2:2,use:[10,57,80,90,95,279],user:[21,241],using:[10,55,295,298],val:53,valid:231,valu:[96,97,98,142,144,145,147,148,149,150,151,152,153,154,155,156,159,160,161,162,163,164,165,166,167,169,170,171,172,174,175,176,177,178,182,183,184,203,204,205,207,208,209,210,211,213,215,222,223,224,225,226,227,228,231,232,233,234,235,236,237,239,240,287,290],variabl:230,vector:134,verif:[134,290],verifi:290,version:[54,57,58,59,80,81,82,279,280],via:[254,278,284,292],view:[287,288,289,292],violat:231,virtualbox:2,visual:12,wait:[264,265],want:[10,242],watch:[242,248],water:286,welcom:9,what:[10,242,248,279],wheel:248,where:280,why:[90,95,279],window:[2,4,8,11,59,60,82,83],work:12,workspac:12,world:[242,266,269,270,271,272,273],would:10,wrapper:2,write:[30,33,63,185,253,261,273,277],yml:[99,280],you:[2,242,248,285],your:[2,7,9,11,12,57,80,186,195,230,242,243,251,253,254,266,269,270,271,272,273,277,278,279,288,292,296],zero:266}})
\ No newline at end of file
+Search.setIndex({docnames:["_static/common","concepts","get_started/docker","get_started/index","get_started/native_install/cross_tools","get_started/native_install/index","get_started/native_install/native_tools","get_started/project_create","get_started/serial_access","index","misc/faq","misc/go_env","misc/ide","misc/index","network/ble/ble_hs/ble_att","network/ble/ble_hs/ble_gap","network/ble/ble_hs/ble_gattc","network/ble/ble_hs/ble_gatts","network/ble/ble_hs/ble_hs","network/ble/ble_hs/ble_hs_id","network/ble/ble_hs/ble_hs_return_codes","network/ble/ble_intro","network/ble/ble_sec","network/ble/ble_setup/ble_addr","network/ble/ble_setup/ble_lp_clock","network/ble/ble_setup/ble_setup_intro","network/ble/ble_setup/ble_sync_cb","network/ble/btshell/btshell_GAP","network/ble/btshell/btshell_GATT","network/ble/btshell/btshell_advdata","network/ble/btshell/btshell_api","network/ble/mesh/index","network/ble/mesh/sample","newt/README","newt/command_list/newt_build","newt/command_list/newt_clean","newt/command_list/newt_complete","newt/command_list/newt_create_image","newt/command_list/newt_debug","newt/command_list/newt_help","newt/command_list/newt_info","newt/command_list/newt_install","newt/command_list/newt_load","newt/command_list/newt_mfg","newt/command_list/newt_new","newt/command_list/newt_pkg","newt/command_list/newt_resign_image","newt/command_list/newt_run","newt/command_list/newt_size","newt/command_list/newt_sync","newt/command_list/newt_target","newt/command_list/newt_test","newt/command_list/newt_upgrade","newt/command_list/newt_vals","newt/command_list/newt_version","newt/index","newt/install/index","newt/install/newt_linux","newt/install/newt_mac","newt/install/newt_windows","newt/install/prev_releases","newt/newt_operation","newt/newt_ops","newtmgr/README","newtmgr/command_list/index","newtmgr/command_list/newtmgr_config","newtmgr/command_list/newtmgr_conn","newtmgr/command_list/newtmgr_crash","newtmgr/command_list/newtmgr_datetime","newtmgr/command_list/newtmgr_echo","newtmgr/command_list/newtmgr_fs","newtmgr/command_list/newtmgr_image","newtmgr/command_list/newtmgr_logs","newtmgr/command_list/newtmgr_mpstats","newtmgr/command_list/newtmgr_reset","newtmgr/command_list/newtmgr_run","newtmgr/command_list/newtmgr_stat","newtmgr/command_list/newtmgr_taskstats","newtmgr/index","newtmgr/install/index","newtmgr/install/install_linux","newtmgr/install/install_mac","newtmgr/install/install_windows","newtmgr/install/prev_releases","os/core_os/callout/callout","os/core_os/context_switch/context_switch","os/core_os/cputime/os_cputime","os/core_os/event_queue/event_queue","os/core_os/heap/heap","os/core_os/mbuf/mbuf","os/core_os/memory_pool/memory_pool","os/core_os/mutex/mutex","os/core_os/mynewt_os","os/core_os/porting/port_bsp","os/core_os/porting/port_cpu","os/core_os/porting/port_mcu","os/core_os/porting/port_os","os/core_os/sanity/sanity","os/core_os/semaphore/semaphore","os/core_os/task/task","os/core_os/time/os_time","os/modules/baselibc","os/modules/bootloader/boot_build_status","os/modules/bootloader/boot_build_status_one","os/modules/bootloader/boot_clear_status","os/modules/bootloader/boot_copy_area","os/modules/bootloader/boot_copy_image","os/modules/bootloader/boot_erase_area","os/modules/bootloader/boot_fill_slot","os/modules/bootloader/boot_find_image_area_idx","os/modules/bootloader/boot_find_image_part","os/modules/bootloader/boot_find_image_slot","os/modules/bootloader/boot_go","os/modules/bootloader/boot_init_flash","os/modules/bootloader/boot_move_area","os/modules/bootloader/boot_read_image_header","os/modules/bootloader/boot_read_image_headers","os/modules/bootloader/boot_read_status","os/modules/bootloader/boot_select_image_slot","os/modules/bootloader/boot_slot_addr","os/modules/bootloader/boot_slot_to_area_idx","os/modules/bootloader/boot_swap_areas","os/modules/bootloader/boot_vect_delete_main","os/modules/bootloader/boot_vect_delete_test","os/modules/bootloader/boot_vect_read_main","os/modules/bootloader/boot_vect_read_one","os/modules/bootloader/boot_vect_read_test","os/modules/bootloader/boot_write_status","os/modules/bootloader/bootloader","os/modules/config/config","os/modules/console/console","os/modules/devmgmt/customize_newtmgr","os/modules/devmgmt/newtmgr","os/modules/devmgmt/oicmgr","os/modules/drivers/driver","os/modules/drivers/flash","os/modules/drivers/mmc","os/modules/elua/elua","os/modules/elua/lua_init","os/modules/elua/lua_main","os/modules/fcb/fcb","os/modules/fcb/fcb_append","os/modules/fcb/fcb_append_finish","os/modules/fcb/fcb_append_to_scratch","os/modules/fcb/fcb_clear","os/modules/fcb/fcb_getnext","os/modules/fcb/fcb_init","os/modules/fcb/fcb_is_empty","os/modules/fcb/fcb_offset_last_n","os/modules/fcb/fcb_rotate","os/modules/fcb/fcb_walk","os/modules/fs/fatfs","os/modules/fs/fs/fs","os/modules/fs/fs/fs_close","os/modules/fs/fs/fs_closedir","os/modules/fs/fs/fs_dirent_is_dir","os/modules/fs/fs/fs_dirent_name","os/modules/fs/fs/fs_filelen","os/modules/fs/fs/fs_getpos","os/modules/fs/fs/fs_mkdir","os/modules/fs/fs/fs_open","os/modules/fs/fs/fs_opendir","os/modules/fs/fs/fs_ops","os/modules/fs/fs/fs_read","os/modules/fs/fs/fs_readdir","os/modules/fs/fs/fs_register","os/modules/fs/fs/fs_rename","os/modules/fs/fs/fs_return_codes","os/modules/fs/fs/fs_seek","os/modules/fs/fs/fs_unlink","os/modules/fs/fs/fs_write","os/modules/fs/fs/fsutil_read_file","os/modules/fs/fs/fsutil_write_file","os/modules/fs/nffs/nffs","os/modules/fs/nffs/nffs_area_desc","os/modules/fs/nffs/nffs_config","os/modules/fs/nffs/nffs_detect","os/modules/fs/nffs/nffs_format","os/modules/fs/nffs/nffs_init","os/modules/fs/nffs/nffs_internals","os/modules/fs/otherfs","os/modules/hal/hal","os/modules/hal/hal_bsp/hal_bsp","os/modules/hal/hal_creation","os/modules/hal/hal_flash/hal_flash","os/modules/hal/hal_flash/hal_flash_int","os/modules/hal/hal_gpio/hal_gpio","os/modules/hal/hal_i2c/hal_i2c","os/modules/hal/hal_in_libraries","os/modules/hal/hal_os_tick/hal_os_tick","os/modules/hal/hal_spi/hal_spi","os/modules/hal/hal_system/hal_sys","os/modules/hal/hal_timer/hal_timer","os/modules/hal/hal_uart/hal_uart","os/modules/hal/hal_watchdog/hal_watchdog","os/modules/imgmgr/imgmgr","os/modules/imgmgr/imgmgr_module_init","os/modules/imgmgr/imgr_ver_parse","os/modules/imgmgr/imgr_ver_str","os/modules/json/json","os/modules/json/json_encode_object_entry","os/modules/json/json_encode_object_finish","os/modules/json/json_encode_object_key","os/modules/json/json_encode_object_start","os/modules/json/json_read_object","os/modules/logs/logs","os/modules/sensor_framework/sensor_api","os/modules/sensor_framework/sensor_create","os/modules/sensor_framework/sensor_driver","os/modules/sensor_framework/sensor_framework_overview","os/modules/sensor_framework/sensor_listener_api","os/modules/sensor_framework/sensor_mgr_api","os/modules/sensor_framework/sensor_oic","os/modules/sensor_framework/sensor_shell","os/modules/shell/shell","os/modules/shell/shell_cmd_register","os/modules/shell/shell_evq_set","os/modules/shell/shell_nlip_input_register","os/modules/shell/shell_nlip_output","os/modules/shell/shell_register","os/modules/shell/shell_register_app_cmd_handler","os/modules/shell/shell_register_default_module","os/modules/split/split","os/modules/stats/stats","os/modules/sysinitconfig/sysconfig_error","os/modules/sysinitconfig/sysinitconfig","os/modules/testutil/test_assert","os/modules/testutil/test_case","os/modules/testutil/test_decl","os/modules/testutil/test_pass","os/modules/testutil/test_suite","os/modules/testutil/testutil","os/modules/testutil/tu_init","os/modules/testutil/tu_restart","os/os_user_guide","os/tutorials/STM32F303","os/tutorials/add_newtmgr","os/tutorials/define_target","os/tutorials/event_queue","os/tutorials/ota_upgrade_nrf52","os/tutorials/pin-wheel-mods","os/tutorials/segger_rtt","os/tutorials/segger_sysview","os/tutorials/tasks_lesson","os/tutorials/try_markdown","tutorials/ble/ble","tutorials/ble/ble_bare_bones","tutorials/ble/blehci_project","tutorials/ble/bleprph/bleprph","tutorials/ble/bleprph/bleprph-sections/bleprph-adv","tutorials/ble/bleprph/bleprph-sections/bleprph-app","tutorials/ble/bleprph/bleprph-sections/bleprph-chr-access","tutorials/ble/bleprph/bleprph-sections/bleprph-gap-event","tutorials/ble/bleprph/bleprph-sections/bleprph-svc-reg","tutorials/ble/eddystone","tutorials/ble/ibeacon","tutorials/blinky/arduino_zero","tutorials/blinky/blinky","tutorials/blinky/blinky_console","tutorials/blinky/blinky_primo","tutorials/blinky/blinky_stm32f4disc","tutorials/blinky/nRF52","tutorials/blinky/olimex","tutorials/blinky/rbnano2","tutorials/lora/lorawanapp","tutorials/other/codesize","tutorials/other/other","tutorials/other/unit_test","tutorials/other/wi-fi_on_arduino","tutorials/repo/add_repos","tutorials/repo/create_repo","tutorials/repo/private_repo","tutorials/repo/upgrade_repo","tutorials/sensors/air_quality","tutorials/sensors/air_quality_ble","tutorials/sensors/air_quality_sensor","tutorials/sensors/nrf52_adc","tutorials/sensors/sensor_bleprph_oic","tutorials/sensors/sensor_nrf52_bno055","tutorials/sensors/sensor_nrf52_bno055_oic","tutorials/sensors/sensor_offboard_config","tutorials/sensors/sensor_oic_overview","tutorials/sensors/sensor_thingy_lis2dh12_onb","tutorials/sensors/sensors","tutorials/sensors/sensors_framework","tutorials/slinky/project-nrf52-slinky","tutorials/slinky/project-sim-slinky","tutorials/slinky/project-slinky","tutorials/slinky/project-stm32-slinky","tutorials/tooling/segger_rtt","tutorials/tooling/segger_sysview","tutorials/tooling/tooling","tutorials/tutorials"],envversion:52,filenames:["_static/common.rst","concepts.rst","get_started/docker.rst","get_started/index.rst","get_started/native_install/cross_tools.rst","get_started/native_install/index.rst","get_started/native_install/native_tools.rst","get_started/project_create.rst","get_started/serial_access.rst","index.rst","misc/faq.rst","misc/go_env.rst","misc/ide.rst","misc/index.rst","network/ble/ble_hs/ble_att.rst","network/ble/ble_hs/ble_gap.rst","network/ble/ble_hs/ble_gattc.rst","network/ble/ble_hs/ble_gatts.rst","network/ble/ble_hs/ble_hs.rst","network/ble/ble_hs/ble_hs_id.rst","network/ble/ble_hs/ble_hs_return_codes.rst","network/ble/ble_intro.rst","network/ble/ble_sec.rst","network/ble/ble_setup/ble_addr.rst","network/ble/ble_setup/ble_lp_clock.rst","network/ble/ble_setup/ble_setup_intro.rst","network/ble/ble_setup/ble_sync_cb.rst","network/ble/btshell/btshell_GAP.rst","network/ble/btshell/btshell_GATT.rst","network/ble/btshell/btshell_advdata.rst","network/ble/btshell/btshell_api.rst","network/ble/mesh/index.rst","network/ble/mesh/sample.rst","newt/README.rst","newt/command_list/newt_build.rst","newt/command_list/newt_clean.rst","newt/command_list/newt_complete.rst","newt/command_list/newt_create_image.rst","newt/command_list/newt_debug.rst","newt/command_list/newt_help.rst","newt/command_list/newt_info.rst","newt/command_list/newt_install.rst","newt/command_list/newt_load.rst","newt/command_list/newt_mfg.rst","newt/command_list/newt_new.rst","newt/command_list/newt_pkg.rst","newt/command_list/newt_resign_image.rst","newt/command_list/newt_run.rst","newt/command_list/newt_size.rst","newt/command_list/newt_sync.rst","newt/command_list/newt_target.rst","newt/command_list/newt_test.rst","newt/command_list/newt_upgrade.rst","newt/command_list/newt_vals.rst","newt/command_list/newt_version.rst","newt/index.rst","newt/install/index.rst","newt/install/newt_linux.rst","newt/install/newt_mac.rst","newt/install/newt_windows.rst","newt/install/prev_releases.rst","newt/newt_operation.rst","newt/newt_ops.rst","newtmgr/README.rst","newtmgr/command_list/index.rst","newtmgr/command_list/newtmgr_config.rst","newtmgr/command_list/newtmgr_conn.rst","newtmgr/command_list/newtmgr_crash.rst","newtmgr/command_list/newtmgr_datetime.rst","newtmgr/command_list/newtmgr_echo.rst","newtmgr/command_list/newtmgr_fs.rst","newtmgr/command_list/newtmgr_image.rst","newtmgr/command_list/newtmgr_logs.rst","newtmgr/command_list/newtmgr_mpstats.rst","newtmgr/command_list/newtmgr_reset.rst","newtmgr/command_list/newtmgr_run.rst","newtmgr/command_list/newtmgr_stat.rst","newtmgr/command_list/newtmgr_taskstats.rst","newtmgr/index.rst","newtmgr/install/index.rst","newtmgr/install/install_linux.rst","newtmgr/install/install_mac.rst","newtmgr/install/install_windows.rst","newtmgr/install/prev_releases.rst","os/core_os/callout/callout.rst","os/core_os/context_switch/context_switch.rst","os/core_os/cputime/os_cputime.rst","os/core_os/event_queue/event_queue.rst","os/core_os/heap/heap.rst","os/core_os/mbuf/mbuf.rst","os/core_os/memory_pool/memory_pool.rst","os/core_os/mutex/mutex.rst","os/core_os/mynewt_os.rst","os/core_os/porting/port_bsp.rst","os/core_os/porting/port_cpu.rst","os/core_os/porting/port_mcu.rst","os/core_os/porting/port_os.rst","os/core_os/sanity/sanity.rst","os/core_os/semaphore/semaphore.rst","os/core_os/task/task.rst","os/core_os/time/os_time.rst","os/modules/baselibc.rst","os/modules/bootloader/boot_build_status.rst","os/modules/bootloader/boot_build_status_one.rst","os/modules/bootloader/boot_clear_status.rst","os/modules/bootloader/boot_copy_area.rst","os/modules/bootloader/boot_copy_image.rst","os/modules/bootloader/boot_erase_area.rst","os/modules/bootloader/boot_fill_slot.rst","os/modules/bootloader/boot_find_image_area_idx.rst","os/modules/bootloader/boot_find_image_part.rst","os/modules/bootloader/boot_find_image_slot.rst","os/modules/bootloader/boot_go.rst","os/modules/bootloader/boot_init_flash.rst","os/modules/bootloader/boot_move_area.rst","os/modules/bootloader/boot_read_image_header.rst","os/modules/bootloader/boot_read_image_headers.rst","os/modules/bootloader/boot_read_status.rst","os/modules/bootloader/boot_select_image_slot.rst","os/modules/bootloader/boot_slot_addr.rst","os/modules/bootloader/boot_slot_to_area_idx.rst","os/modules/bootloader/boot_swap_areas.rst","os/modules/bootloader/boot_vect_delete_main.rst","os/modules/bootloader/boot_vect_delete_test.rst","os/modules/bootloader/boot_vect_read_main.rst","os/modules/bootloader/boot_vect_read_one.rst","os/modules/bootloader/boot_vect_read_test.rst","os/modules/bootloader/boot_write_status.rst","os/modules/bootloader/bootloader.rst","os/modules/config/config.rst","os/modules/console/console.rst","os/modules/devmgmt/customize_newtmgr.rst","os/modules/devmgmt/newtmgr.rst","os/modules/devmgmt/oicmgr.rst","os/modules/drivers/driver.rst","os/modules/drivers/flash.rst","os/modules/drivers/mmc.rst","os/modules/elua/elua.rst","os/modules/elua/lua_init.rst","os/modules/elua/lua_main.rst","os/modules/fcb/fcb.rst","os/modules/fcb/fcb_append.rst","os/modules/fcb/fcb_append_finish.rst","os/modules/fcb/fcb_append_to_scratch.rst","os/modules/fcb/fcb_clear.rst","os/modules/fcb/fcb_getnext.rst","os/modules/fcb/fcb_init.rst","os/modules/fcb/fcb_is_empty.rst","os/modules/fcb/fcb_offset_last_n.rst","os/modules/fcb/fcb_rotate.rst","os/modules/fcb/fcb_walk.rst","os/modules/fs/fatfs.rst","os/modules/fs/fs/fs.rst","os/modules/fs/fs/fs_close.rst","os/modules/fs/fs/fs_closedir.rst","os/modules/fs/fs/fs_dirent_is_dir.rst","os/modules/fs/fs/fs_dirent_name.rst","os/modules/fs/fs/fs_filelen.rst","os/modules/fs/fs/fs_getpos.rst","os/modules/fs/fs/fs_mkdir.rst","os/modules/fs/fs/fs_open.rst","os/modules/fs/fs/fs_opendir.rst","os/modules/fs/fs/fs_ops.rst","os/modules/fs/fs/fs_read.rst","os/modules/fs/fs/fs_readdir.rst","os/modules/fs/fs/fs_register.rst","os/modules/fs/fs/fs_rename.rst","os/modules/fs/fs/fs_return_codes.rst","os/modules/fs/fs/fs_seek.rst","os/modules/fs/fs/fs_unlink.rst","os/modules/fs/fs/fs_write.rst","os/modules/fs/fs/fsutil_read_file.rst","os/modules/fs/fs/fsutil_write_file.rst","os/modules/fs/nffs/nffs.rst","os/modules/fs/nffs/nffs_area_desc.rst","os/modules/fs/nffs/nffs_config.rst","os/modules/fs/nffs/nffs_detect.rst","os/modules/fs/nffs/nffs_format.rst","os/modules/fs/nffs/nffs_init.rst","os/modules/fs/nffs/nffs_internals.rst","os/modules/fs/otherfs.rst","os/modules/hal/hal.rst","os/modules/hal/hal_bsp/hal_bsp.rst","os/modules/hal/hal_creation.rst","os/modules/hal/hal_flash/hal_flash.rst","os/modules/hal/hal_flash/hal_flash_int.rst","os/modules/hal/hal_gpio/hal_gpio.rst","os/modules/hal/hal_i2c/hal_i2c.rst","os/modules/hal/hal_in_libraries.rst","os/modules/hal/hal_os_tick/hal_os_tick.rst","os/modules/hal/hal_spi/hal_spi.rst","os/modules/hal/hal_system/hal_sys.rst","os/modules/hal/hal_timer/hal_timer.rst","os/modules/hal/hal_uart/hal_uart.rst","os/modules/hal/hal_watchdog/hal_watchdog.rst","os/modules/imgmgr/imgmgr.rst","os/modules/imgmgr/imgmgr_module_init.rst","os/modules/imgmgr/imgr_ver_parse.rst","os/modules/imgmgr/imgr_ver_str.rst","os/modules/json/json.rst","os/modules/json/json_encode_object_entry.rst","os/modules/json/json_encode_object_finish.rst","os/modules/json/json_encode_object_key.rst","os/modules/json/json_encode_object_start.rst","os/modules/json/json_read_object.rst","os/modules/logs/logs.rst","os/modules/sensor_framework/sensor_api.rst","os/modules/sensor_framework/sensor_create.rst","os/modules/sensor_framework/sensor_driver.rst","os/modules/sensor_framework/sensor_framework_overview.rst","os/modules/sensor_framework/sensor_listener_api.rst","os/modules/sensor_framework/sensor_mgr_api.rst","os/modules/sensor_framework/sensor_oic.rst","os/modules/sensor_framework/sensor_shell.rst","os/modules/shell/shell.rst","os/modules/shell/shell_cmd_register.rst","os/modules/shell/shell_evq_set.rst","os/modules/shell/shell_nlip_input_register.rst","os/modules/shell/shell_nlip_output.rst","os/modules/shell/shell_register.rst","os/modules/shell/shell_register_app_cmd_handler.rst","os/modules/shell/shell_register_default_module.rst","os/modules/split/split.rst","os/modules/stats/stats.rst","os/modules/sysinitconfig/sysconfig_error.rst","os/modules/sysinitconfig/sysinitconfig.rst","os/modules/testutil/test_assert.rst","os/modules/testutil/test_case.rst","os/modules/testutil/test_decl.rst","os/modules/testutil/test_pass.rst","os/modules/testutil/test_suite.rst","os/modules/testutil/testutil.rst","os/modules/testutil/tu_init.rst","os/modules/testutil/tu_restart.rst","os/os_user_guide.rst","os/tutorials/STM32F303.rst","os/tutorials/add_newtmgr.rst","os/tutorials/define_target.rst","os/tutorials/event_queue.rst","os/tutorials/ota_upgrade_nrf52.rst","os/tutorials/pin-wheel-mods.rst","os/tutorials/segger_rtt.rst","os/tutorials/segger_sysview.rst","os/tutorials/tasks_lesson.rst","os/tutorials/try_markdown.rst","tutorials/ble/ble.rst","tutorials/ble/ble_bare_bones.rst","tutorials/ble/blehci_project.rst","tutorials/ble/bleprph/bleprph.rst","tutorials/ble/bleprph/bleprph-sections/bleprph-adv.rst","tutorials/ble/bleprph/bleprph-sections/bleprph-app.rst","tutorials/ble/bleprph/bleprph-sections/bleprph-chr-access.rst","tutorials/ble/bleprph/bleprph-sections/bleprph-gap-event.rst","tutorials/ble/bleprph/bleprph-sections/bleprph-svc-reg.rst","tutorials/ble/eddystone.rst","tutorials/ble/ibeacon.rst","tutorials/blinky/arduino_zero.rst","tutorials/blinky/blinky.rst","tutorials/blinky/blinky_console.rst","tutorials/blinky/blinky_primo.rst","tutorials/blinky/blinky_stm32f4disc.rst","tutorials/blinky/nRF52.rst","tutorials/blinky/olimex.rst","tutorials/blinky/rbnano2.rst","tutorials/lora/lorawanapp.rst","tutorials/other/codesize.rst","tutorials/other/other.rst","tutorials/other/unit_test.rst","tutorials/other/wi-fi_on_arduino.rst","tutorials/repo/add_repos.rst","tutorials/repo/create_repo.rst","tutorials/repo/private_repo.rst","tutorials/repo/upgrade_repo.rst","tutorials/sensors/air_quality.rst","tutorials/sensors/air_quality_ble.rst","tutorials/sensors/air_quality_sensor.rst","tutorials/sensors/nrf52_adc.rst","tutorials/sensors/sensor_bleprph_oic.rst","tutorials/sensors/sensor_nrf52_bno055.rst","tutorials/sensors/sensor_nrf52_bno055_oic.rst","tutorials/sensors/sensor_offboard_config.rst","tutorials/sensors/sensor_oic_overview.rst","tutorials/sensors/sensor_thingy_lis2dh12_onb.rst","tutorials/sensors/sensors.rst","tutorials/sensors/sensors_framework.rst","tutorials/slinky/project-nrf52-slinky.rst","tutorials/slinky/project-sim-slinky.rst","tutorials/slinky/project-slinky.rst","tutorials/slinky/project-stm32-slinky.rst","tutorials/tooling/segger_rtt.rst","tutorials/tooling/segger_sysview.rst","tutorials/tooling/tooling.rst","tutorials/tutorials.rst"],objects:{"":{"HALGpio::HAL_GPIO_MODE_IN":[186,1,1,"c.HALGpio::HAL_GPIO_MODE_IN"],"HALGpio::HAL_GPIO_MODE_NC":[186,1,1,"c.HALGpio::HAL_GPIO_MODE_NC"],"HALGpio::HAL_GPIO_MODE_OUT":[186,1,1,"c.HALGpio::HAL_GPIO_MODE_OUT"],"HALGpio::HAL_GPIO_PULL_DOWN":[186,1,1,"c.HALGpio::HAL_GPIO_PULL_DOWN"],"HALGpio::HAL_GPIO_PULL_NONE":[186,1,1,"c.HALGpio::HAL_GPIO_PULL_NONE"],"HALGpio::HAL_GPIO_PULL_UP":[186,1,1,"c.HALGpio::HAL_GPIO_PULL_UP"],"HALGpio::HAL_GPIO_TRIG_BOTH":[186,1,1,"c.HALGpio::HAL_GPIO_TRIG_BOTH"],"HALGpio::HAL_GPIO_TRIG_FALLING":[186,1,1,"c.HALGpio::HAL_GPIO_TRIG_FALLING"],"HALGpio::HAL_GPIO_TRIG_HIGH":[186,1,1,"c.HALGpio::HAL_GPIO_TRIG_HIGH"],"HALGpio::HAL_GPIO_TRIG_LOW":[186,1,1,"c.HALGpio::HAL_GPIO_TRIG_LOW"],"HALGpio::HAL_GPIO_TRIG_NONE":[186,1,1,"c.HALGpio::HAL_GPIO_TRIG_NONE"],"HALGpio::HAL_GPIO_TRIG_RISING":[186,1,1,"c.HALGpio::HAL_GPIO_TRIG_RISING"],"HALGpio::hal_gpio_irq_trigger":[186,2,1,"c.HALGpio::hal_gpio_irq_trigger"],"HALGpio::hal_gpio_mode_e":[186,2,1,"c.HALGpio::hal_gpio_mode_e"],"HALGpio::hal_gpio_pull":[186,2,1,"c.HALGpio::hal_gpio_pull"],"HALSystem::HAL_RESET_BROWNOUT":[191,1,1,"c.HALSystem::HAL_RESET_BROWNOUT"],"HALSystem::HAL_RESET_PIN":[191,1,1,"c.HALSystem::HAL_RESET_PIN"],"HALSystem::HAL_RESET_POR":[191,1,1,"c.HALSystem::HAL_RESET_POR"],"HALSystem::HAL_RESET_REQUESTED":[191,1,1,"c.HALSystem::HAL_RESET_REQUESTED"],"HALSystem::HAL_RESET_SOFT":[191,1,1,"c.HALSystem::HAL_RESET_SOFT"],"HALSystem::HAL_RESET_WATCHDOG":[191,1,1,"c.HALSystem::HAL_RESET_WATCHDOG"],"HALSystem::hal_reset_reason":[191,2,1,"c.HALSystem::hal_reset_reason"],"HALUart::HAL_UART_FLOW_CTL_NONE":[193,1,1,"c.HALUart::HAL_UART_FLOW_CTL_NONE"],"HALUart::HAL_UART_FLOW_CTL_RTS_CTS":[193,1,1,"c.HALUart::HAL_UART_FLOW_CTL_RTS_CTS"],"HALUart::HAL_UART_PARITY_EVEN":[193,1,1,"c.HALUart::HAL_UART_PARITY_EVEN"],"HALUart::HAL_UART_PARITY_NONE":[193,1,1,"c.HALUart::HAL_UART_PARITY_NONE"],"HALUart::HAL_UART_PARITY_ODD":[193,1,1,"c.HALUart::HAL_UART_PARITY_ODD"],"HALUart::hal_uart_flow_ctl":[193,2,1,"c.HALUart::hal_uart_flow_ctl"],"HALUart::hal_uart_parity":[193,2,1,"c.HALUart::hal_uart_parity"],"OSTask::OS_TASK_READY":[99,1,1,"c.OSTask::OS_TASK_READY"],"OSTask::OS_TASK_SLEEP":[99,1,1,"c.OSTask::OS_TASK_SLEEP"],"OSTask::os_task_state":[99,2,1,"c.OSTask::os_task_state"],"hal_i2c_master_data::address":[187,6,1,"c.hal_i2c_master_data::address"],"hal_i2c_master_data::buffer":[187,6,1,"c.hal_i2c_master_data::buffer"],"hal_spi_settings::baudrate":[190,6,1,"c.hal_spi_settings::baudrate"],"hal_spi_settings::data_mode":[190,6,1,"c.hal_spi_settings::data_mode"],"hal_spi_settings::data_order":[190,6,1,"c.hal_spi_settings::data_order"],"hal_spi_settings::word_size":[190,6,1,"c.hal_spi_settings::word_size"],"hal_timer::bsp_timer":[192,6,1,"c.hal_timer::bsp_timer"],"hal_timer::cb_arg":[192,6,1,"c.hal_timer::cb_arg"],"hal_timer::cb_func":[192,6,1,"c.hal_timer::cb_func"],"hal_timer::expiry":[192,6,1,"c.hal_timer::expiry"],"os_callout::c_ev":[84,6,1,"c.os_callout::c_ev"],"os_callout::c_evq":[84,6,1,"c.os_callout::c_evq"],"os_callout::c_ticks":[84,6,1,"c.os_callout::c_ticks"],"os_event::ev_arg":[87,6,1,"c.os_event::ev_arg"],"os_event::ev_cb":[87,6,1,"c.os_event::ev_cb"],"os_event::ev_queued":[87,6,1,"c.os_event::ev_queued"],"os_eventq::evq_owner":[87,6,1,"c.os_eventq::evq_owner"],"os_eventq::evq_task":[87,6,1,"c.os_eventq::evq_task"],"os_mbuf::om_data":[89,6,1,"c.os_mbuf::om_data"],"os_mbuf::om_flags":[89,6,1,"c.os_mbuf::om_flags"],"os_mbuf::om_len":[89,6,1,"c.os_mbuf::om_len"],"os_mbuf::om_omp":[89,6,1,"c.os_mbuf::om_omp"],"os_mbuf::om_pkthdr_len":[89,6,1,"c.os_mbuf::om_pkthdr_len"],"os_mbuf_pkthdr::omp_flags":[89,6,1,"c.os_mbuf_pkthdr::omp_flags"],"os_mbuf_pkthdr::omp_len":[89,6,1,"c.os_mbuf_pkthdr::omp_len"],"os_mbuf_pool::omp_databuf_len":[89,6,1,"c.os_mbuf_pool::omp_databuf_len"],"os_mbuf_pool::omp_pool":[89,6,1,"c.os_mbuf_pool::omp_pool"],"os_mempool::mp_block_size":[90,6,1,"c.os_mempool::mp_block_size"],"os_mempool::mp_flags":[90,6,1,"c.os_mempool::mp_flags"],"os_mempool::mp_membuf_addr":[90,6,1,"c.os_mempool::mp_membuf_addr"],"os_mempool::mp_min_free":[90,6,1,"c.os_mempool::mp_min_free"],"os_mempool::mp_num_blocks":[90,6,1,"c.os_mempool::mp_num_blocks"],"os_mempool::mp_num_free":[90,6,1,"c.os_mempool::mp_num_free"],"os_mempool::name":[90,6,1,"c.os_mempool::name"],"os_mempool_info::omi_block_size":[90,6,1,"c.os_mempool_info::omi_block_size"],"os_mempool_info::omi_min_free":[90,6,1,"c.os_mempool_info::omi_min_free"],"os_mempool_info::omi_num_blocks":[90,6,1,"c.os_mempool_info::omi_num_blocks"],"os_mempool_info::omi_num_free":[90,6,1,"c.os_mempool_info::omi_num_free"],"os_mqueue::mq_ev":[89,6,1,"c.os_mqueue::mq_ev"],"os_mutex::SLIST_HEAD":[91,3,1,"c.os_mutex::SLIST_HEAD"],"os_mutex::_pad":[91,6,1,"c.os_mutex::_pad"],"os_mutex::mu_level":[91,6,1,"c.os_mutex::mu_level"],"os_mutex::mu_owner":[91,6,1,"c.os_mutex::mu_owner"],"os_mutex::mu_prio":[91,6,1,"c.os_mutex::mu_prio"],"os_sanity_check::sc_arg":[97,6,1,"c.os_sanity_check::sc_arg"],"os_sanity_check::sc_checkin_itvl":[97,6,1,"c.os_sanity_check::sc_checkin_itvl"],"os_sanity_check::sc_checkin_last":[97,6,1,"c.os_sanity_check::sc_checkin_last"],"os_sanity_check::sc_func":[97,6,1,"c.os_sanity_check::sc_func"],"os_sem::sem_tokens":[98,6,1,"c.os_sem::sem_tokens"],"os_task::t_arg":[99,6,1,"c.os_task::t_arg"],"os_task::t_ctx_sw_cnt":[99,6,1,"c.os_task::t_ctx_sw_cnt"],"os_task::t_flags":[99,6,1,"c.os_task::t_flags"],"os_task::t_func":[99,6,1,"c.os_task::t_func"],"os_task::t_name":[99,6,1,"c.os_task::t_name"],"os_task::t_next_wakeup":[99,6,1,"c.os_task::t_next_wakeup"],"os_task::t_obj":[99,6,1,"c.os_task::t_obj"],"os_task::t_prio":[99,6,1,"c.os_task::t_prio"],"os_task::t_run_time":[99,6,1,"c.os_task::t_run_time"],"os_task::t_sanity_check":[99,6,1,"c.os_task::t_sanity_check"],"os_task::t_stackptr":[99,6,1,"c.os_task::t_stackptr"],"os_task::t_stacksize":[99,6,1,"c.os_task::t_stacksize"],"os_task::t_stacktop":[99,6,1,"c.os_task::t_stacktop"],"os_task::t_taskid":[99,6,1,"c.os_task::t_taskid"],"os_task_info::oti_cswcnt":[99,6,1,"c.os_task_info::oti_cswcnt"],"os_task_info::oti_last_checkin":[99,6,1,"c.os_task_info::oti_last_checkin"],"os_task_info::oti_next_checkin":[99,6,1,"c.os_task_info::oti_next_checkin"],"os_task_info::oti_prio":[99,6,1,"c.os_task_info::oti_prio"],"os_task_info::oti_runtime":[99,6,1,"c.os_task_info::oti_runtime"],"os_task_info::oti_state":[99,6,1,"c.os_task_info::oti_state"],"os_task_info::oti_stksize":[99,6,1,"c.os_task_info::oti_stksize"],"os_task_info::oti_stkusage":[99,6,1,"c.os_task_info::oti_stkusage"],"os_task_info::oti_taskid":[99,6,1,"c.os_task_info::oti_taskid"],"os_timezone::tz_dsttime":[100,6,1,"c.os_timezone::tz_dsttime"],"os_timezone::tz_minuteswest":[100,6,1,"c.os_timezone::tz_minuteswest"],CPUTIME_GEQ:[86,0,1,"c.CPUTIME_GEQ"],CPUTIME_GT:[86,0,1,"c.CPUTIME_GT"],CPUTIME_LEQ:[86,0,1,"c.CPUTIME_LEQ"],CPUTIME_LT:[86,0,1,"c.CPUTIME_LT"],HAL_BSP_MAX_ID_LEN:[182,0,1,"c.HAL_BSP_MAX_ID_LEN"],HAL_BSP_POWER_DEEP_SLEEP:[182,0,1,"c.HAL_BSP_POWER_DEEP_SLEEP"],HAL_BSP_POWER_OFF:[182,0,1,"c.HAL_BSP_POWER_OFF"],HAL_BSP_POWER_ON:[182,0,1,"c.HAL_BSP_POWER_ON"],HAL_BSP_POWER_PERUSER:[182,0,1,"c.HAL_BSP_POWER_PERUSER"],HAL_BSP_POWER_SLEEP:[182,0,1,"c.HAL_BSP_POWER_SLEEP"],HAL_BSP_POWER_WFI:[182,0,1,"c.HAL_BSP_POWER_WFI"],HAL_SPI_LSB_FIRST:[190,0,1,"c.HAL_SPI_LSB_FIRST"],HAL_SPI_MODE0:[190,0,1,"c.HAL_SPI_MODE0"],HAL_SPI_MODE1:[190,0,1,"c.HAL_SPI_MODE1"],HAL_SPI_MODE2:[190,0,1,"c.HAL_SPI_MODE2"],HAL_SPI_MODE3:[190,0,1,"c.HAL_SPI_MODE3"],HAL_SPI_MSB_FIRST:[190,0,1,"c.HAL_SPI_MSB_FIRST"],HAL_SPI_TYPE_MASTER:[190,0,1,"c.HAL_SPI_TYPE_MASTER"],HAL_SPI_TYPE_SLAVE:[190,0,1,"c.HAL_SPI_TYPE_SLAVE"],HAL_SPI_WORD_SIZE_8BIT:[190,0,1,"c.HAL_SPI_WORD_SIZE_8BIT"],HAL_SPI_WORD_SIZE_9BIT:[190,0,1,"c.HAL_SPI_WORD_SIZE_9BIT"],OS_CALLOUT_F_QUEUED:[84,0,1,"c.OS_CALLOUT_F_QUEUED"],OS_EVENT_QUEUED:[87,0,1,"c.OS_EVENT_QUEUED"],OS_MBUF_DATA:[89,0,1,"c.OS_MBUF_DATA"],OS_MBUF_F_MASK:[89,0,1,"c.OS_MBUF_F_MASK"],OS_MBUF_IS_PKTHDR:[89,0,1,"c.OS_MBUF_IS_PKTHDR"],OS_MBUF_LEADINGSPACE:[89,0,1,"c.OS_MBUF_LEADINGSPACE"],OS_MBUF_PKTHDR:[89,0,1,"c.OS_MBUF_PKTHDR"],OS_MBUF_PKTHDR_TO_MBUF:[89,0,1,"c.OS_MBUF_PKTHDR_TO_MBUF"],OS_MBUF_PKTLEN:[89,0,1,"c.OS_MBUF_PKTLEN"],OS_MBUF_TRAILINGSPACE:[89,0,1,"c.OS_MBUF_TRAILINGSPACE"],OS_MBUF_USRHDR:[89,0,1,"c.OS_MBUF_USRHDR"],OS_MBUF_USRHDR_LEN:[89,0,1,"c.OS_MBUF_USRHDR_LEN"],OS_MEMPOOL_BYTES:[90,0,1,"c.OS_MEMPOOL_BYTES"],OS_MEMPOOL_F_EXT:[90,0,1,"c.OS_MEMPOOL_F_EXT"],OS_MEMPOOL_INFO_NAME_LEN:[90,0,1,"c.OS_MEMPOOL_INFO_NAME_LEN"],OS_MEMPOOL_SIZE:[90,0,1,"c.OS_MEMPOOL_SIZE"],OS_SANITY_CHECK_SETFUNC:[97,0,1,"c.OS_SANITY_CHECK_SETFUNC"],OS_TASK_FLAG_EVQ_WAIT:[99,0,1,"c.OS_TASK_FLAG_EVQ_WAIT"],OS_TASK_FLAG_MUTEX_WAIT:[99,0,1,"c.OS_TASK_FLAG_MUTEX_WAIT"],OS_TASK_FLAG_NO_TIMEOUT:[99,0,1,"c.OS_TASK_FLAG_NO_TIMEOUT"],OS_TASK_FLAG_SEM_WAIT:[99,0,1,"c.OS_TASK_FLAG_SEM_WAIT"],OS_TASK_MAX_NAME_LEN:[99,0,1,"c.OS_TASK_MAX_NAME_LEN"],OS_TASK_PRI_HIGHEST:[99,0,1,"c.OS_TASK_PRI_HIGHEST"],OS_TASK_PRI_LOWEST:[99,0,1,"c.OS_TASK_PRI_LOWEST"],OS_TIMEOUT_NEVER:[100,0,1,"c.OS_TIMEOUT_NEVER"],OS_TIME_MAX:[100,0,1,"c.OS_TIME_MAX"],OS_TIME_TICK_GEQ:[100,0,1,"c.OS_TIME_TICK_GEQ"],OS_TIME_TICK_GT:[100,0,1,"c.OS_TIME_TICK_GT"],OS_TIME_TICK_LT:[100,0,1,"c.OS_TIME_TICK_LT"],_sbrk:[182,3,1,"c._sbrk"],completion_cb:[130,4,1,"c.completion_cb"],console_append_char_cb:[130,4,1,"c.console_append_char_cb"],console_blocking_mode:[130,3,1,"c.console_blocking_mode"],console_echo:[130,3,1,"c.console_echo"],console_handle_char:[130,3,1,"c.console_handle_char"],console_init:[130,3,1,"c.console_init"],console_input:[130,5,1,"c.console_input"],console_is_init:[130,3,1,"c.console_is_init"],console_is_midline:[130,6,1,"c.console_is_midline"],console_non_blocking_mode:[130,3,1,"c.console_non_blocking_mode"],console_out:[130,3,1,"c.console_out"],console_printf:[130,3,1,"c.console_printf"],console_read:[130,3,1,"c.console_read"],console_rx_cb:[130,4,1,"c.console_rx_cb"],console_set_completion_cb:[130,3,1,"c.console_set_completion_cb"],console_set_queues:[130,3,1,"c.console_set_queues"],console_write:[130,3,1,"c.console_write"],hal_bsp_core_dump:[182,3,1,"c.hal_bsp_core_dump"],hal_bsp_flash_dev:[182,3,1,"c.hal_bsp_flash_dev"],hal_bsp_get_nvic_priority:[182,3,1,"c.hal_bsp_get_nvic_priority"],hal_bsp_hw_id:[182,3,1,"c.hal_bsp_hw_id"],hal_bsp_init:[182,3,1,"c.hal_bsp_init"],hal_bsp_power_state:[182,3,1,"c.hal_bsp_power_state"],hal_debugger_connected:[191,3,1,"c.hal_debugger_connected"],hal_flash_align:[184,3,1,"c.hal_flash_align"],hal_flash_erase:[184,3,1,"c.hal_flash_erase"],hal_flash_erase_sector:[184,3,1,"c.hal_flash_erase_sector"],hal_flash_init:[184,3,1,"c.hal_flash_init"],hal_flash_ioctl:[184,3,1,"c.hal_flash_ioctl"],hal_flash_read:[184,3,1,"c.hal_flash_read"],hal_flash_write:[184,3,1,"c.hal_flash_write"],hal_gpio_init_in:[186,3,1,"c.hal_gpio_init_in"],hal_gpio_init_out:[186,3,1,"c.hal_gpio_init_out"],hal_gpio_irq_disable:[186,3,1,"c.hal_gpio_irq_disable"],hal_gpio_irq_enable:[186,3,1,"c.hal_gpio_irq_enable"],hal_gpio_irq_handler_t:[186,4,1,"c.hal_gpio_irq_handler_t"],hal_gpio_irq_init:[186,3,1,"c.hal_gpio_irq_init"],hal_gpio_irq_release:[186,3,1,"c.hal_gpio_irq_release"],hal_gpio_irq_trig_t:[186,4,1,"c.hal_gpio_irq_trig_t"],hal_gpio_mode_t:[186,4,1,"c.hal_gpio_mode_t"],hal_gpio_pull_t:[186,4,1,"c.hal_gpio_pull_t"],hal_gpio_read:[186,3,1,"c.hal_gpio_read"],hal_gpio_toggle:[186,3,1,"c.hal_gpio_toggle"],hal_gpio_write:[186,3,1,"c.hal_gpio_write"],hal_i2c_init:[187,3,1,"c.hal_i2c_init"],hal_i2c_master_data:[187,7,1,"_CPPv319hal_i2c_master_data"],hal_i2c_master_probe:[187,3,1,"c.hal_i2c_master_probe"],hal_i2c_master_read:[187,3,1,"c.hal_i2c_master_read"],hal_i2c_master_write:[187,3,1,"c.hal_i2c_master_write"],hal_reset_cause:[191,3,1,"c.hal_reset_cause"],hal_spi_abort:[190,3,1,"c.hal_spi_abort"],hal_spi_config:[190,3,1,"c.hal_spi_config"],hal_spi_data_mode_breakout:[190,3,1,"c.hal_spi_data_mode_breakout"],hal_spi_disable:[190,3,1,"c.hal_spi_disable"],hal_spi_enable:[190,3,1,"c.hal_spi_enable"],hal_spi_init:[190,3,1,"c.hal_spi_init"],hal_spi_set_txrx_cb:[190,3,1,"c.hal_spi_set_txrx_cb"],hal_spi_settings:[190,7,1,"_CPPv316hal_spi_settings"],hal_spi_slave_set_def_tx_val:[190,3,1,"c.hal_spi_slave_set_def_tx_val"],hal_spi_tx_val:[190,3,1,"c.hal_spi_tx_val"],hal_spi_txrx:[190,3,1,"c.hal_spi_txrx"],hal_spi_txrx_cb:[190,4,1,"c.hal_spi_txrx_cb"],hal_spi_txrx_noblock:[190,3,1,"c.hal_spi_txrx_noblock"],hal_system_clock_start:[191,3,1,"c.hal_system_clock_start"],hal_system_reset:[191,3,1,"c.hal_system_reset"],hal_system_restart:[191,3,1,"c.hal_system_restart"],hal_system_start:[191,3,1,"c.hal_system_start"],hal_timer:[192,7,1,"_CPPv39hal_timer"],hal_timer_cb:[192,4,1,"c.hal_timer_cb"],hal_timer_config:[192,3,1,"c.hal_timer_config"],hal_timer_deinit:[192,3,1,"c.hal_timer_deinit"],hal_timer_delay:[192,3,1,"c.hal_timer_delay"],hal_timer_get_resolution:[192,3,1,"c.hal_timer_get_resolution"],hal_timer_init:[192,3,1,"c.hal_timer_init"],hal_timer_read:[192,3,1,"c.hal_timer_read"],hal_timer_set_cb:[192,3,1,"c.hal_timer_set_cb"],hal_timer_start:[192,3,1,"c.hal_timer_start"],hal_timer_start_at:[192,3,1,"c.hal_timer_start_at"],hal_timer_stop:[192,3,1,"c.hal_timer_stop"],hal_uart_blocking_tx:[193,3,1,"c.hal_uart_blocking_tx"],hal_uart_close:[193,3,1,"c.hal_uart_close"],hal_uart_config:[193,3,1,"c.hal_uart_config"],hal_uart_init:[193,3,1,"c.hal_uart_init"],hal_uart_init_cbs:[193,3,1,"c.hal_uart_init_cbs"],hal_uart_rx_char:[193,4,1,"c.hal_uart_rx_char"],hal_uart_start_rx:[193,3,1,"c.hal_uart_start_rx"],hal_uart_start_tx:[193,3,1,"c.hal_uart_start_tx"],hal_uart_tx_char:[193,4,1,"c.hal_uart_tx_char"],hal_uart_tx_done:[193,4,1,"c.hal_uart_tx_done"],hal_watchdog_enable:[194,3,1,"c.hal_watchdog_enable"],hal_watchdog_init:[194,3,1,"c.hal_watchdog_init"],hal_watchdog_tickle:[194,3,1,"c.hal_watchdog_tickle"],os_callout:[84,7,1,"_CPPv310os_callout"],os_callout_init:[84,3,1,"c.os_callout_init"],os_callout_queued:[84,3,1,"c.os_callout_queued"],os_callout_remaining_ticks:[84,3,1,"c.os_callout_remaining_ticks"],os_callout_reset:[84,3,1,"c.os_callout_reset"],os_callout_stop:[84,3,1,"c.os_callout_stop"],os_cputime_delay_nsecs:[86,3,1,"c.os_cputime_delay_nsecs"],os_cputime_delay_ticks:[86,3,1,"c.os_cputime_delay_ticks"],os_cputime_delay_usecs:[86,3,1,"c.os_cputime_delay_usecs"],os_cputime_get32:[86,3,1,"c.os_cputime_get32"],os_cputime_init:[86,3,1,"c.os_cputime_init"],os_cputime_nsecs_to_ticks:[86,3,1,"c.os_cputime_nsecs_to_ticks"],os_cputime_ticks_to_nsecs:[86,3,1,"c.os_cputime_ticks_to_nsecs"],os_cputime_ticks_to_usecs:[86,3,1,"c.os_cputime_ticks_to_usecs"],os_cputime_timer_init:[86,3,1,"c.os_cputime_timer_init"],os_cputime_timer_relative:[86,3,1,"c.os_cputime_timer_relative"],os_cputime_timer_start:[86,3,1,"c.os_cputime_timer_start"],os_cputime_timer_stop:[86,3,1,"c.os_cputime_timer_stop"],os_cputime_usecs_to_ticks:[86,3,1,"c.os_cputime_usecs_to_ticks"],os_event:[87,7,1,"_CPPv38os_event"],os_event_fn:[87,4,1,"c.os_event_fn"],os_eventq:[87,7,1,"_CPPv39os_eventq"],os_eventq_dflt_get:[87,3,1,"c.os_eventq_dflt_get"],os_eventq_get:[87,3,1,"c.os_eventq_get"],os_eventq_get_no_wait:[87,3,1,"c.os_eventq_get_no_wait"],os_eventq_init:[87,3,1,"c.os_eventq_init"],os_eventq_inited:[87,3,1,"c.os_eventq_inited"],os_eventq_poll:[87,3,1,"c.os_eventq_poll"],os_eventq_put:[87,3,1,"c.os_eventq_put"],os_eventq_remove:[87,3,1,"c.os_eventq_remove"],os_eventq_run:[87,3,1,"c.os_eventq_run"],os_get_uptime_usec:[100,3,1,"c.os_get_uptime_usec"],os_gettimeofday:[100,3,1,"c.os_gettimeofday"],os_mbuf:[89,7,1,"_CPPv37os_mbuf"],os_mbuf_adj:[89,3,1,"c.os_mbuf_adj"],os_mbuf_append:[89,3,1,"c.os_mbuf_append"],os_mbuf_appendfrom:[89,3,1,"c.os_mbuf_appendfrom"],os_mbuf_cmpf:[89,3,1,"c.os_mbuf_cmpf"],os_mbuf_cmpm:[89,3,1,"c.os_mbuf_cmpm"],os_mbuf_concat:[89,3,1,"c.os_mbuf_concat"],os_mbuf_copydata:[89,3,1,"c.os_mbuf_copydata"],os_mbuf_copyinto:[89,3,1,"c.os_mbuf_copyinto"],os_mbuf_dup:[89,3,1,"c.os_mbuf_dup"],os_mbuf_extend:[89,3,1,"c.os_mbuf_extend"],os_mbuf_free:[89,3,1,"c.os_mbuf_free"],os_mbuf_free_chain:[89,3,1,"c.os_mbuf_free_chain"],os_mbuf_get:[89,3,1,"c.os_mbuf_get"],os_mbuf_get_pkthdr:[89,3,1,"c.os_mbuf_get_pkthdr"],os_mbuf_off:[89,3,1,"c.os_mbuf_off"],os_mbuf_pkthdr:[89,7,1,"_CPPv314os_mbuf_pkthdr"],os_mbuf_pool:[89,7,1,"_CPPv312os_mbuf_pool"],os_mbuf_pool_init:[89,3,1,"c.os_mbuf_pool_init"],os_mbuf_prepend:[89,3,1,"c.os_mbuf_prepend"],os_mbuf_prepend_pullup:[89,3,1,"c.os_mbuf_prepend_pullup"],os_mbuf_pullup:[89,3,1,"c.os_mbuf_pullup"],os_mbuf_trim_front:[89,3,1,"c.os_mbuf_trim_front"],os_memblock:[90,7,1,"_CPPv311os_memblock"],os_memblock_from:[90,3,1,"c.os_memblock_from"],os_memblock_get:[90,3,1,"c.os_memblock_get"],os_memblock_put:[90,3,1,"c.os_memblock_put"],os_memblock_put_from_cb:[90,3,1,"c.os_memblock_put_from_cb"],os_membuf_t:[90,4,1,"c.os_membuf_t"],os_mempool:[90,7,1,"_CPPv310os_mempool"],os_mempool_ext_init:[90,3,1,"c.os_mempool_ext_init"],os_mempool_info:[90,7,1,"_CPPv315os_mempool_info"],os_mempool_info_get_next:[90,3,1,"c.os_mempool_info_get_next"],os_mempool_init:[90,3,1,"c.os_mempool_init"],os_mempool_is_sane:[90,3,1,"c.os_mempool_is_sane"],os_mempool_put_fn:[90,4,1,"c.os_mempool_put_fn"],os_mqueue:[89,7,1,"_CPPv39os_mqueue"],os_mqueue_get:[89,3,1,"c.os_mqueue_get"],os_mqueue_init:[89,3,1,"c.os_mqueue_init"],os_mqueue_put:[89,3,1,"c.os_mqueue_put"],os_msys_count:[89,3,1,"c.os_msys_count"],os_msys_get:[89,3,1,"c.os_msys_get"],os_msys_get_pkthdr:[89,3,1,"c.os_msys_get_pkthdr"],os_msys_num_free:[89,3,1,"c.os_msys_num_free"],os_msys_register:[89,3,1,"c.os_msys_register"],os_msys_reset:[89,3,1,"c.os_msys_reset"],os_mutex:[91,7,1,"_CPPv38os_mutex"],os_mutex_init:[91,3,1,"c.os_mutex_init"],os_mutex_pend:[91,3,1,"c.os_mutex_pend"],os_mutex_release:[91,3,1,"c.os_mutex_release"],os_sanity_check:[97,7,1,"_CPPv315os_sanity_check"],os_sanity_check_func_t:[97,4,1,"c.os_sanity_check_func_t"],os_sanity_check_init:[97,3,1,"c.os_sanity_check_init"],os_sanity_check_register:[97,3,1,"c.os_sanity_check_register"],os_sanity_check_reset:[97,3,1,"c.os_sanity_check_reset"],os_sanity_task_checkin:[97,3,1,"c.os_sanity_task_checkin"],os_sched_get_current_task:[85,3,1,"c.os_sched_get_current_task"],os_sem:[98,7,1,"_CPPv36os_sem"],os_sem_get_count:[98,3,1,"c.os_sem_get_count"],os_sem_init:[98,3,1,"c.os_sem_init"],os_sem_pend:[98,3,1,"c.os_sem_pend"],os_sem_release:[98,3,1,"c.os_sem_release"],os_settimeofday:[100,3,1,"c.os_settimeofday"],os_stime_t:[100,4,1,"c.os_stime_t"],os_task:[99,7,1,"_CPPv37os_task"],os_task_count:[99,3,1,"c.os_task_count"],os_task_func_t:[99,4,1,"c.os_task_func_t"],os_task_info:[99,7,1,"_CPPv312os_task_info"],os_task_info_get_next:[99,3,1,"c.os_task_info_get_next"],os_task_init:[99,3,1,"c.os_task_init"],os_task_remove:[99,3,1,"c.os_task_remove"],os_task_state_t:[99,4,1,"c.os_task_state_t"],os_tick_idle:[189,3,1,"c.os_tick_idle"],os_tick_init:[189,3,1,"c.os_tick_init"],os_time_advance:[100,3,1,"c.os_time_advance"],os_time_delay:[100,3,1,"c.os_time_delay"],os_time_get:[100,3,1,"c.os_time_get"],os_time_ms_to_ticks:[100,3,1,"c.os_time_ms_to_ticks"],os_time_t:[100,4,1,"c.os_time_t"],os_timeradd:[100,0,1,"c.os_timeradd"],os_timersub:[100,0,1,"c.os_timersub"],os_timeval:[100,7,1,"_CPPv310os_timeval"],os_timezone:[100,7,1,"_CPPv311os_timezone"]}},objnames:{"0":["c","define","define"],"1":["c","enumvalue","enumvalue"],"2":["c","enum","enum"],"3":["c","function","C function"],"4":["c","typedef","typedef"],"5":["c","struct","struct"],"6":["c","variable","variable"],"7":["cpp","class","C++ class"]},objtypes:{"0":"c:define","1":"c:enumvalue","2":"c:enum","3":"c:function","4":"c:typedef","5":"c:struct","6":"c:variable","7":"cpp:class"},terms:{"000s":[259,261,264,276],"008s":[259,261,264,276],"00z":267,"01t22":68,"02t22":267,"04x":20,"05t02":267,"093s":[259,261,264,276],"0b1000110":187,"0mb":11,"0ubuntu5":6,"0x0":[256,263,276],"0x00":[20,263,264,275],"0x0000":[247,275],"0x00000000":[179,222,224,225],"0x00000001":128,"0x00000002":[128,263],"0x00000004":128,"0x00000008":128,"0x00000010":128,"0x000000b8":256,"0x000000d8":[241,242,289,290],"0x000000dc":[241,242,246,282,289,290],"0x00004000":[222,224,225],"0x00008000":[93,222,224,225],"0x00009ef4":263,"0x0000fca6":256,"0x00023800":222,"0x0003f000":222,"0x0003f800":222,"0x0006":29,"0x0007d000":225,"0x000e0000":224,"0x0010":27,"0x01":[20,27,30,128,264],"0x0100":27,"0x01000000":262,"0x0101":20,"0x0102":20,"0x0103":20,"0x0104":20,"0x0105":20,"0x0106":20,"0x0107":20,"0x0108":20,"0x0109":20,"0x010a":20,"0x010b":20,"0x010c":20,"0x010d":20,"0x010e":20,"0x010f":20,"0x0110":20,"0x0111":20,"0x02":[20,27,30,128,264,275],"0x0201":20,"0x0202":20,"0x0203":20,"0x0204":20,"0x0205":20,"0x0206":20,"0x0207":20,"0x0208":20,"0x0209":20,"0x020a":20,"0x020b":20,"0x020c":20,"0x020d":20,"0x020e":20,"0x020f":20,"0x0210":20,"0x0211":20,"0x0212":20,"0x0213":20,"0x0214":20,"0x0215":20,"0x0216":20,"0x0217":20,"0x0218":20,"0x0219":20,"0x021a":20,"0x021b":20,"0x021c":20,"0x021d":20,"0x021e":20,"0x021f":20,"0x0220":20,"0x0221":20,"0x0222":20,"0x0223":20,"0x0224":20,"0x0225":20,"0x0226":20,"0x0227":20,"0x0228":20,"0x0229":20,"0x022a":20,"0x022c":20,"0x022d":20,"0x022e":20,"0x022f":20,"0x0230":20,"0x0232":20,"0x0234":20,"0x0235":20,"0x0236":20,"0x0237":20,"0x0238":20,"0x0239":20,"0x023a":20,"0x023b":20,"0x023c":20,"0x023d":20,"0x023e":20,"0x023f":20,"0x0240":20,"0x03":[20,30,128],"0x0300":[20,27],"0x0301":20,"0x0302":20,"0x04":[20,27],"0x0401":20,"0x0402":20,"0x0403":20,"0x0404":20,"0x0405":20,"0x0406":20,"0x0407":20,"0x0408":20,"0x0409":20,"0x040a":20,"0x040b":20,"0x040c":20,"0x040d":20,"0x040e":20,"0x0483":260,"0x05":20,"0x0501":20,"0x0502":20,"0x0503":20,"0x0504":20,"0x0505":20,"0x0506":20,"0x0507":20,"0x0508":20,"0x0509":20,"0x050a":20,"0x050b":20,"0x050c":20,"0x050d":20,"0x050e":20,"0x06":[20,247],"0x07":20,"0x08":[20,27,275],"0x08000000":262,"0x08000020":262,"0x08000250":262,"0x08021e90":260,"0x09":20,"0x0a":20,"0x0b":20,"0x0bc11477":256,"0x0c":20,"0x0c80":29,"0x0d":20,"0x0e":20,"0x0f":[20,278],"0x0f505235":128,"0x0fffffff":179,"0x1":[276,278,280,282],"0x10":[20,256,263,264,278],"0x100":20,"0x1000":[89,278,280],"0x10000":93,"0x10000000":179,"0x10010000":262,"0x10036413":262,"0x10076413":260,"0x1010":89,"0x103":20,"0x11":[20,23,255,264],"0x12":20,"0x13":20,"0x14":20,"0x1400":275,"0x15":[20,274,276,278],"0x16":20,"0x17":20,"0x18":20,"0x1800":30,"0x1808":30,"0x180a":30,"0x19":[20,207],"0x1a":20,"0x1b":20,"0x1c":[20,274,276],"0x1d":20,"0x1e":20,"0x1f":20,"0x2":[278,280],"0x20":[20,32,93,256,263,274,276],"0x200":[20,278,280],"0x2000":[278,280],"0x20000":276,"0x20000000":93,"0x20002290":260,"0x20002408":256,"0x20008000":256,"0x21":[20,32],"0x21000000":256,"0x22":[20,23,32,264],"0x23":[20,32],"0x24":20,"0x25":[20,275],"0x26":20,"0x27":20,"0x28":20,"0x2800":275,"0x29":20,"0x2a":20,"0x2ba01477":263,"0x2c":20,"0x2d":20,"0x2e":20,"0x2f":20,"0x30":[20,256,263],"0x300":20,"0x311":278,"0x32":[20,278],"0x33":23,"0x34":20,"0x35":20,"0x36":20,"0x37":20,"0x374b":260,"0x38":20,"0x39":20,"0x3a":20,"0x3a000":93,"0x3b":20,"0x3c":20,"0x3c00":275,"0x3d":20,"0x3e":20,"0x3f":20,"0x4":[278,280],"0x40":[20,256,263,274,276],"0x400":20,"0x4000":[278,280],"0x40007000":276,"0x4001e504":263,"0x4001e50c":263,"0x40number":187,"0x41000000":260,"0x42000":61,"0x44":[23,275],"0x4400":275,"0x46":187,"0x4f":[274,276],"0x50":[256,263],"0x500":20,"0x5000":275,"0x55":23,"0x60":[256,263],"0x61":[274,276],"0x66":23,"0x6c00":275,"0x70":[256,263],"0x72":[274,276],"0x7800":275,"0x7fefd260":128,"0x7fff8000":276,"0x7fffffff":179,"0x80":[274,276],"0x8000":61,"0x8000000":262,"0x80000000":179,"0x8079b62c":128,"0x81":187,"0x8801":275,"0x8c":187,"0x8d":187,"0x90":[274,276],"0x96f3b83c":128,"0x9c01":275,"0x9f":275,"0xa0":278,"0xa001":275,"0xa7":[274,276],"0xaf":[274,276],"0xb3":[274,276],"0xb401":275,"0xb5":[274,276],"0xbead":[274,276],"0xcc01":275,"0xd2":[274,276],"0xd801":275,"0xdead":[274,276],"0xe401":275,"0xe7":[274,276],"0xf":275,"0xf001":275,"0xf395c277":128,"0xfb":278,"0xfe":275,"0xff":[128,179],"0xffff":[29,190,275],"0xfffffffe":179,"0xffffffff":[91,98,128,179,206,256],"0xffffffff0xffffffff0xffffffff0xffffffff":263,"100kb":101,"1024kbyte":[260,262],"103kb":222,"10m":27,"110kb":222,"128kb":[9,224],"12c":[259,261,264,276],"12kb":225,"12mhz":9,"132425ssb":30,"132428ssb":30,"132433ssb":30,"132437ssb":30,"132441ssb":30,"14e":[241,289],"14h":[241,282,289],"1503a0":268,"16kb":[9,224,225],"16kbram":53,"16mb":9,"190a192":275,"1_amd64":[57,60,80,83],"1c15":[274,276],"1d11":285,"1d13":[268,288],"1d560":222,"1eec4":222,"1kb":222,"1st":68,"1ubuntu1":6,"1wx":263,"200mhz":9,"2015q2":[4,12],"2022609336ssb":250,"2022687456ssb":250,"2022789012ssb":250,"2022851508ssb":250,"2042859320ssb":250,"2042937440ssb":250,"248m":6,"250m":238,"256kb":256,"262s":[259,261,264,276],"28a29":275,"28t22":267,"291ebc02a8c345911c96fdf4e7b9015a843697658fd6b5faa0eb257a23e93682":239,"296712s":262,"2a24":48,"2d5217f":81,"2m_interval_max":27,"2m_interval_min":27,"2m_latenc":27,"2m_max_conn_event_len":27,"2m_min_conn_event_len":27,"2m_scan_interv":27,"2m_scan_window":27,"2m_timeout":27,"2msym":21,"300v":[259,261,264,276],"32kb":[225,256],"32mb":9,"32wx":[256,263],"363s":[259,261,264,276],"3_1":36,"3mb":81,"4_9":4,"4fa7":[274,276],"500m":238,"512kb":93,"575c":222,"5kb":101,"6lowpan":21,"73d77f":71,"78e4d263eeb5af5635705b7cae026cc184f14aa6c6c59c6e80616035cd2efc8f":222,"7b3w9m4n2mg3sqmgw2q1b9p80000gn":55,"7kb":222,"8ab6433f8971b05c2a9c3341533e8ddb754e404":271,"948f118966f7989628f8f3be28840fd23a200fc219bb72acdfe9096f06c4b39b":222,"9cf8af22b1b573909a8290a90c066d4e190407e97680b7a32243960ec2bf3a7f":288,"9mb":58,"abstract":[9,20,95,96,134,151,162,165,173,180,206,208,209,238,275,292],"boolean":[199,225],"break":[20,89,136,233,251,275],"byte":[10,19,23,27,46,66,71,73,89,90,99,128,130,132,140,141,153,157,158,160,163,168,169,170,171,172,173,174,179,182,187,190,193,199,222,226,239,243,254,255,264],"case":[2,6,7,20,21,30,55,64,65,66,67,68,69,70,71,72,73,74,75,76,77,80,81,82,89,92,93,97,98,99,128,134,173,179,183,222,223,225,226,227,228,229,230,231,233,235,242,243,247,251,252,254,255,256,267,268,274,275,276,290],"catch":20,"char":[90,92,97,99,129,130,134,138,139,152,154,155,156,159,160,161,162,164,166,169,171,172,176,177,179,193,197,198,199,200,202,205,214,215,219,220,221,223,225,232,238,243,251,254,255,258,267,275,280,282],"class":[134,264],"const":[87,89,90,93,99,128,130,135,152,154,155,156,157,158,159,160,161,162,164,165,166,169,170,171,172,176,177,180,182,184,185,199,204,205,208,214,219,221,223,251,253,254,255,267,274,275,276],"default":[1,2,4,6,7,10,12,20,24,26,27,28,34,35,37,38,39,40,41,42,43,44,45,46,47,48,49,50,51,52,53,54,57,58,59,61,62,64,65,66,67,68,69,70,71,72,73,74,75,76,77,80,81,82,87,89,91,92,93,94,96,97,99,130,131,133,134,135,151,175,190,199,205,206,207,208,209,211,212,213,214,216,221,222,223,224,225,235,236,238,239,241,247,249,251,254,255,256,257,264,269,274,275,276,278,279,281,282,284,289],"enum":[99,129,186,191,193,199,206,274,275],"export":[1,11,23,60,61,80,82,83,87,130,134,136,205,206,207,208,209,236,277,278,280],"final":[8,55,89,91,93,128,142,179,181,201,222,240,243,246,249,274,276],"float":[64,65,66,67,68,69,70,71,72,73,74,75,76,77,80,81,82,101,199,206,277],"function":[1,7,9,14,20,23,31,61,84,86,87,88,89,90,92,94,95,96,97,99,128,129,130,134,135,136,138,146,150,151,152,153,154,155,156,158,160,161,162,164,166,167,168,169,171,173,174,176,179,180,181,183,186,187,188,189,190,191,192,193,196,198,200,201,202,203,204,205,207,209,212,214,215,216,217,219,220,222,226,227,228,229,230,232,233,235,236,238,239,241,242,246,249,250,252,254,255,257,258,264,267,269,274,275,276,278,282,287,289,290,292],"goto":[97,159,204,208,217,218,274,275,276],"i\u00b2c":187,"import":[11,55,57,80,89,93,100,101,187,243,246,249,252,276],"int":[1,20,26,34,35,37,38,39,40,41,42,43,44,45,46,47,48,49,50,51,52,53,54,57,58,59,62,64,65,66,67,68,69,70,71,72,73,74,75,76,77,80,81,82,84,86,87,89,90,92,97,99,100,129,130,134,135,136,138,139,141,142,143,144,145,146,147,148,149,150,152,153,154,155,156,157,159,160,161,162,163,164,165,166,168,169,170,171,172,176,177,178,180,182,183,184,186,187,189,190,191,192,193,194,197,198,199,200,201,202,203,204,207,208,214,215,217,218,219,220,221,223,225,226,227,228,230,231,232,238,240,243,249,251,252,253,254,255,258,267,274,275,276,280,282],"long":[3,21,24,28,89,92,98,101,151,169,179,187,222,263,282],"new":[2,3,4,6,10,11,21,23,24,27,30,31,34,39,41,45,46,50,53,57,58,59,61,85,89,93,96,99,128,130,140,141,142,151,152,161,166,173,176,177,181,187,195,214,222,223,225,235,239,243,245,246,247,252,253,254,255,256,259,260,261,262,263,264,267,268,269,275,276,277,279,292],"null":[84,86,87,89,90,91,92,93,97,98,99,130,135,152,156,160,163,171,173,179,185,190,204,205,207,208,214,219,221,224,225,238,243,249,252,253,254,255,258,274,275,276,277,280,282],"public":[19,25,27,29,30,32,57,66,80,84,87,89,90,91,97,98,99,100,128,130,187,190,192,254,255],"return":[18,26,84,85,86,87,89,90,91,92,93,97,98,99,100,129,130,135,140,152,182,185,186,187,190,191,192,193,194,199,207,208,211,225,238,243,249,251,252,253,256,258,264,267,274,275,276,278,280,282,286],"short":[89,91,214,243],"static":[19,26,66,84,87,90,92,93,97,98,129,130,135,139,180,198,200,201,203,204,205,207,208,215,217,218,219,220,221,226,235,238,247,249,251,252,253,254,255,258,274,275,276,277,280,282],"switch":[10,12,20,58,71,77,81,85,92,93,99,128,181,195,214,236,241,246,247,251,252,274,275,276,282,289],"transient":252,"true":[8,12,86,90,97,100,204,222,226,239,267,276,285,288],"try":[2,20,21,23,89,152,179,187,235,240,241,246,247,250,256,257,258,259,260,261,263,268,270,276,278,282,284,289],"var":[50,55,65,66,97,166],"void":[20,26,84,85,86,87,89,90,92,97,99,100,129,130,134,135,136,138,150,152,153,157,159,160,162,163,166,168,169,170,171,172,178,180,182,183,184,186,187,189,190,191,192,193,194,196,198,199,205,207,208,210,215,216,217,219,220,221,225,226,227,228,230,231,232,233,238,243,249,251,252,253,254,255,258,274,275,276,277,280,282],"while":[4,6,7,8,21,23,26,49,55,61,89,90,92,93,97,99,101,130,136,138,152,154,155,156,161,164,179,193,199,204,208,222,225,226,231,236,238,241,242,243,254,255,258,265,267,274,275,276,280,282,289,290],AES:22,ANS:248,Adding:[56,79,292],And:[61,128,140,222,224,240,243,245,250,274,275,276],But:276,CTS:[193,247],FOR:4,For:[2,3,5,6,7,8,11,12,20,22,23,24,29,30,34,37,39,50,53,55,57,58,59,60,61,62,66,83,84,89,92,93,96,100,101,128,134,135,152,170,173,174,179,180,183,186,187,190,199,205,206,207,208,209,210,220,222,223,224,225,231,233,235,238,239,241,242,246,251,252,253,254,255,256,258,260,261,262,264,267,268,269,270,275,276,278,280,282,285,288,289,290,292],IDE:[5,12],IDs:128,Its:[94,100,101,235,270],NOT:[156,187,192,276],Not:[7,20,29,86,89,179,181,186,190,222,276],One:[6,20,92,101,179,222,235,249,268,275],PCs:8,QoS:[20,21],RTS:[193,247],Such:[179,254,255,270],TMS:256,That:[2,20,61,140,179,225,254,255,256,264,268,269,275,276],The:[1,2,3,4,5,6,7,8,10,11,12,14,15,16,17,18,19,20,21,22,23,24,26,27,29,30,31,33,34,37,43,45,46,47,50,55,57,58,59,61,63,64,66,70,71,72,73,75,76,77,78,80,81,82,84,85,86,87,88,89,90,91,92,93,94,95,96,97,98,99,100,101,128,129,130,131,132,133,134,135,136,140,152,153,154,155,156,157,158,159,160,161,162,163,164,165,166,168,169,170,172,173,174,175,176,177,179,180,181,182,183,184,185,186,187,189,190,191,192,193,194,195,197,198,199,205,206,207,208,209,210,211,212,213,214,215,217,218,219,220,222,223,224,225,226,229,231,233,234,235,236,238,239,240,241,242,243,244,245,246,247,249,251,252,253,254,255,256,257,259,260,261,262,263,264,265,267,268,269,270,274,275,276,277,278,279,280,281,282,284,285,286,287,288,289,290,292],Then:[10,33,63,128,140,179,222,235,241,247,267,275,276,289],There:[4,8,10,22,23,28,57,61,80,84,89,91,93,94,98,99,100,101,129,130,134,160,179,181,186,205,206,211,214,222,223,241,242,251,256,264,267,271,276,282,289,290],These:[5,20,27,50,61,89,93,94,96,98,128,129,134,179,187,206,209,210,211,214,224,236,245,249,253,254,255,256,257,262,269,270,277,278],Use:[1,7,8,11,27,28,50,57,58,59,62,71,80,81,82,93,132,140,142,222,235,251,254,255,256,259,264,268,269,276,277,279,287],Used:[93,190,193,227,228,230],Uses:[31,42,133,224],Using:[20,49,91,258,287,292],Was:264,Will:20,With:[9,20,21,30,89,92,96,128,222,224,240,241,242,243,246,275,289,290,292],Yes:[10,19,89,128,133,244],__arg:97,__asm:260,__builtin_offsetof:223,__etext:262,__ev:87,__f:97,__hdr:89,__itvl:97,__n:89,__om:89,__omp:89,__sc:97,__t1:[86,100],__t2:[86,100],__type:89,__wfi:260,_access:251,_adc:276,_addr:254,_addr_:[254,255],_app:254,_build:[33,63],_cfg:[207,208],_cli:[208,209,278],_cnt:140,_config:[206,207,208,280],_file:152,_gatt_ac:251,_imghdr_siz:93,_init:[206,207,208],_log:208,_name:225,_nrf52_adc_h_:276,_object:199,_ofb:[207,209,278],_onb:[207,209,282],_pad1:128,_pad2:128,_pad3:128,_pad:[91,128],_param:214,_rea:199,_reserv:206,_resource_t:277,_sbrk:182,_senseair_h_:275,_sensor:207,_set:254,_shell_init:[208,278],_stage:225,_stat:208,a600anj1:222,abbrevi:249,abc:267,abil:[6,22,31,55,89,243],abl:[2,89,93,134,135,236,244,250,254,255,256,269,275,276],abort:[49,190,215,219,224,225,226,267,280],about:[1,3,10,23,29,40,57,58,59,62,64,80,81,82,90,92,93,97,99,100,140,141,145,179,199,210,222,223,234,235,238,243,249,252,253,254,255,259,263,264,270,275,276],abov:[9,10,14,19,89,92,97,100,128,152,160,179,187,190,214,222,223,224,225,236,246,249,251,254,255,258,264,267,269,274,276],absent:[128,179],absolut:[89,192],abstrat:140,acc:278,accel:[278,282],accel_rev:278,acceleromet:[206,208,277,278,279,282],accept:[20,27,136,160,179,187,193,195,235,256,260,262,264,269],access:[15,20,21,27,59,61,64,70,80,81,82,86,88,89,91,92,93,98,134,135,136,140,152,160,167,169,173,180,181,187,195,205,206,208,209,222,225,231,238,246,253,256,267,275],access_:253,access_cb:[251,253,274],access_fla:160,access_flag:[160,162],accgyro:278,accommod:[24,89,96,128,179,254],accomplish:[9,10,55,173,179,251],accord:[93,128,231,232],accordingli:[24,93,99],account:[10,61,89,128],accur:262,achiev:[26,179,254,255],ack_rxd:264,acknowledg:264,acl:20,acquir:[26,91,98,179,187],acquisit:187,across:[30,31,55,61,62,134,179,181],act:[22,30,195,222],action:[9,27,62,235,243,249,253,264,276],activ:[12,16,17,21,47,71,93,99,190,195,222,235,239,241,242,249,264,285,288,289,290],actual:[2,7,34,77,89,93,99,128,156,163,171,179,183,194,222,224,226,234,243,246,254,255,256,269,270,271,275,276],ad_fil:152,adafruit:[8,276,278],adapt:[21,96,256,259,260,268,282],adapter_nsrst_delai:[256,260],adaptor:262,adc0:276,adc:[9,53,134],adc_0:276,adc_0_interrupt_prior:276,adc_0_oversampl:276,adc_0_resolut:276,adc_buf_read:276,adc_buf_releas:276,adc_buf_s:276,adc_buf_set:276,adc_chan_config:276,adc_config:276,adc_dev:276,adc_event_handler_set:276,adc_evq:276,adc_hw_impl:53,adc_init:276,adc_nrf52:276,adc_number_channel:276,adc_number_sampl:276,adc_read:276,adc_read_ev:276,adc_result:276,adc_result_mv:276,adc_sampl:276,adc_sns_str:276,adc_sns_typ:276,adc_sns_val:276,adc_stack:276,adc_stack_s:276,adc_stm32f4:134,adc_task:276,adc_task_handl:276,adc_task_prio:276,add:[1,2,4,6,7,11,12,27,37,39,50,55,57,58,59,61,62,80,87,89,92,96,98,100,101,130,131,140,152,181,187,207,208,215,223,225,235,236,238,239,240,243,246,247,250,256,257,258,265,267,268,269,278,279,280,281,283,285,286,287,288,292],added:[10,12,32,53,55,81,89,93,98,99,128,130,135,137,152,187,214,238,239,256,258,268,270,274,275,285,286,288,292],adding:[2,10,31,37,55,89,93,94,100,140,223,246,258,267,269,270,274,275,276],addit:[1,12,21,29,43,55,61,62,89,93,94,96,128,134,152,179,187,205,222,225,226,229,235,236,243,246,249,256,257,259,260,262,263,264,275,286],addition:62,addr:[27,30,135,199,204,247,254,255,278],addr_typ:[27,30],address:[20,21,22,25,27,29,31,32,55,66,89,90,92,128,134,135,136,151,179,184,187,190,199,206,208,222,239,241,247,251,264,268,282,289],aditihilbert:4,adjust:[20,89,93,238,240],admin:[4,247],adress:27,adsertis:27,adv:[21,27,30,31],adv_data:27,adv_field:[249,254],adv_param:[249,252,254,255],advanc:[59,168,179,241,242,289,290],advantag:252,advantang:249,adverb:62,adverti:[254,255],advertis:[15,20,21,24,26,31,32,66,239,248,250,252,274,276,277],advertise_128bit_uuid:277,advertise_16bit_uuid:277,advertising_interv:[27,29],advic:[94,95],advinterv:29,aes:[256,259,261,263,268,285,286,288],aesni:[285,286],af80:[274,276],affect:[128,168,173,174,180,205,222,246,265],aflag:[1,50,61],after:[4,8,11,22,26,30,41,50,55,57,58,61,80,81,86,89,90,94,99,100,128,129,134,138,142,146,152,173,179,187,190,193,208,222,224,229,235,236,239,243,244,247,249,251,252,253,256,257,268,269,278,282],again:[8,20,26,57,59,80,93,99,128,140,222,223,243,249,256,259,260,261,262,263,264,274,276,288],against:[22,89,92,100],agnost:152,agre:[275,276],agreement:[275,276],ah02mie2:275,ahead:100,aid:[61,208],aim:[20,135,152,248,292],ain0:276,ain1:276,air:[20,89,222,236,264,283,292],air_q:275,air_qual:[274,275,276],albeit:245,alert:248,algorithm:[21,85],align:[89,90,140,243],all201612161220:75,all:[1,2,3,6,7,8,9,10,12,14,15,16,17,18,20,21,22,24,26,27,28,29,30,31,35,40,41,43,49,50,51,52,53,55,61,66,72,75,89,91,92,93,94,96,97,99,100,128,129,130,134,140,144,150,152,159,160,163,165,166,169,171,173,175,177,179,180,181,183,190,199,205,206,207,208,209,210,211,212,214,219,222,223,224,225,229,231,234,235,236,240,244,246,247,248,249,250,251,252,253,254,255,258,260,262,264,265,267,269,270,271,272,274,275,276,278,280,282,285,288],alloc:[73,77,87,88,89,90,151,179,219,249,251],allow:[2,3,4,6,8,9,12,20,21,27,31,39,50,55,57,58,59,64,65,66,67,68,69,70,71,72,73,74,75,76,77,80,81,82,87,89,91,92,96,98,128,130,134,152,173,179,182,187,190,191,205,209,210,211,213,214,222,223,225,228,232,235,236,238,243,247,249,252,254,258,259,264,268,276,278,282,284],almost:[8,243],alon:232,along:[10,61,89,90,99,217,275],alongsid:[243,254],alphabet:[179,225],alreadi:[6,7,8,11,20,24,31,43,58,59,81,82,86,95,96,128,135,146,153,159,160,165,166,167,172,179,186,192,235,240,241,242,245,246,256,258,259,260,261,262,263,264,268,274,275,276,277,285,288,289,290],also:[1,3,5,6,7,8,11,12,21,23,24,27,34,37,40,55,57,58,59,60,61,66,80,83,89,90,92,93,96,98,99,100,128,129,130,131,134,135,140,152,173,179,190,193,195,205,206,207,208,210,212,214,222,223,224,225,235,236,238,243,246,249,252,253,257,258,264,265,267,268,269,270,274,275,276,278,279,280,281,282,285,286,288],alt:288,altern:[6,128,140,222,251],although:269,altogeth:[84,274],alwai:[8,61,93,100,128,156,158,160,161,168,170,179,183,245,251,254,255,262,267,269,270,275,292],ambigu:20,ambiti:246,amd64:[57,80],amend:[1,32,50,62,239,241,242,265,289,290],amg:278,among:[85,93,128,176,222],amongst:89,amount:[24,89,90,95,152,171,205,222,243,249],analog:[134,283],analyz:[12,242,290],android:[277,279,281,284],ani:[1,4,8,10,14,21,22,27,33,49,50,59,61,63,64,66,73,76,77,80,81,82,84,86,87,89,90,91,92,93,95,97,98,99,100,128,130,135,136,152,159,169,173,174,175,176,178,179,190,193,205,208,209,214,222,223,225,232,235,236,239,247,249,258,259,264,270,274,275,276,282,287,292],announc:[249,254,255],annoy:[251,271],anonym:27,anoth:[10,21,26,27,30,61,89,91,92,93,94,95,98,99,100,130,186,195,222,224,235,241,242,243,249,251,264,275,276,286,289,290],ans:[275,276],answer:92,anymor:[89,243],anyth:[1,8,23,34,35,37,38,39,40,41,42,43,44,45,46,47,48,49,50,51,52,53,54,57,58,59,62,222,235,240,246,254,255,257,270,275,276],apach:[1,2,6,7,10,11,12,21,32,33,37,38,39,43,44,50,51,53,55,57,58,59,61,62,63,80,81,82,84,93,128,130,133,134,152,183,222,223,225,235,241,242,244,246,247,248,250,254,256,257,258,259,260,261,262,263,264,267,268,269,270,275,276,277,278,279,282,284,285,286,287,288,289,290,292],apart:100,api:[1,16,17,18,19,20,21,53,55,61,92,96,134,135,162,181,185,208,209,214,223,255,260,277,281],app:[1,7,8,12,21,26,29,32,34,37,38,42,43,45,46,47,48,50,53,55,62,73,76,77,93,128,130,134,152,181,191,223,224,225,235,236,238,239,240,241,243,246,248,249,252,253,254,255,256,258,259,260,261,262,263,267,268,274,275,276,277,278,279,280,281,285,286,287,288,289,292],app_error:276,app_log_init:205,app_util_platform:276,appear:[27,29,96,187,243,251,253],append:[89,140,158,168,170,179,267],append_loc:[141,142],append_test:267,appl:[241,242,256,282,284,289,290],appli:[12,24,100,128,130,173,174,179,193,205,222,225,264,267],applic:[1,2,4,5,6,8,9,10,11,13,14,18,20,21,23,24,25,26,28,30,34,39,42,47,50,55,57,58,59,60,61,73,76,77,78,82,83,87,89,93,97,99,128,130,131,132,133,134,152,173,179,184,190,208,209,210,211,212,213,214,220,223,224,225,234,239,242,245,248,251,252,257,266,267,274,275,281,284,286,287,290,292],applicaton:1,applict:12,approach:[31,93,225],appropri:[62,89,93,96,99,132,134,179,187,190,225,235,240,246,249,252,254,255,257,275,276,281],approv:10,apps_air_qu:275,apps_bleprph:222,apps_blinki:[55,61],apps_my_sensor_app:282,apr:[259,261,264,276],apropo:[241,242,256,282,289,290],apt:[4,6,7,56,60,79,83,247],arbitrari:[128,235,247,256,259,260,261,262,263,264,268,276,278,285,286,288],arbitrarili:[128,179,255],arc4:256,arch:[61,93,96,231,259,260,261,262,263,264,282],arch_sim:[258,282],architectur:[57,80,85,90,93,95,96,100,128,134,151,181,186,243],archiv:[4,7,57,59,61,166,235,236,246,256,258,259,260,261,262,263,264,268,275,276,278,282,285,286,288],arduino:[12,243,257,266,269,274,275,292],arduino_101:53,arduino_blinki:[12,243,256],arduino_boot:[12,256],arduino_mkr1000:268,arduino_primo_nrf52:[53,259,275],arduino_zero:256,arduino_zero_debug:256,arduinowifi:268,area:[89,93,128,129,140,150,174,176,177,182,225],area_cnt:182,area_desc:[176,177],aren:101,arg:[12,86,89,90,92,97,99,134,150,184,186,190,192,193,205,208,217,226,238,243,251,252,274,275,276,282],argc:[92,99,129,138,139,176,177,197,214,215,219,220,221,225,232,238,243,254,255,258,267,275,280,282],argument:[11,12,20,45,50,55,62,84,87,89,90,97,99,100,130,167,183,186,187,190,192,199,205,208,210,214,220,243,249,252,253,254,255,259,261,269,270,282],argv:[99,129,138,139,176,177,197,214,215,219,220,221,225,232,238,243,254,255,258,267,275,280,282],arm:[5,6,7,12,84,93,101,241,242,256,262,282,288,289,290],around:[30,89,128,276,277,279],arrai:[23,87,139,140,150,173,174,176,177,190,199,200,201,203,204,214,219,225,240,243,249,253],arrang:[93,222],arriv:89,articl:271,artifact:[35,39,50,55,57,58,59,269],ascii:179,asf:[1,269,275,276],ask:[10,92,129,193,206,243,262,269,270,275],aspect:[27,89,128,243],assembl:[1,61,93,96,259,260,261,262,263,264,282],assert:[67,89,97,130,157,170,176,177,190,207,223,226,238,243,251,252,253,254,255,258,274,275,276,280,282],assign:[10,19,21,23,29,37,50,53,66,90,92,93,99,140,179,180,225,235,251,256,259,260,261,262,263,264,268,276,278,285,288],associ:[22,24,87,89,97,99,128,192,225,226,249,252],assum:[7,12,30,43,59,60,82,83,87,89,93,99,128,135,190,195,225,235,236,238,240,241,242,245,246,258,264,274,275,276,277,279,281,282,289,290],asynchron:193,at45db:135,at45db_default_config:135,at45db_dev:135,at45db_erase_sector:135,at45db_init:135,at45db_read:135,at45db_sector_info:135,at45db_writ:135,at45dbxxx:135,at91samd21g18:256,at91samd:256,ate_m:206,atmel:[2,256,268],atop:[134,181],att:[18,21,28,251],attach:[8,12,89,93,186,191,241,242,246,259,264,276,282,289,290],attempt:[20,23,27,89,90,91,99,128,163,171,176,177,178,179,187,225,251,252,253,264],attempt_stat:223,attent:3,attr:[28,30,204],attr_handl:[250,251,252,274,276],attribit:199,attribut:[14,16,17,20,21,28,50,53,62,66,90,94,96,199,204,225,248,251],auth:[27,271],authent:[20,22,30,128,250],author:[1,20,43,61,130,267,275,276],auto:[29,135],autocomplet:55,autoconf:55,autom:31,automat:[1,10,21,24,25,42,55,61,94,196,214,223,225,229,236,246,248,249,256,259,260,262,263,267,269,275,276,277,292],autoselect:256,avaial:264,avail:[1,2,3,4,7,9,20,21,23,24,29,30,31,32,47,57,58,59,62,64,73,80,81,82,87,89,90,91,97,98,101,128,130,132,134,140,152,163,173,193,195,206,214,222,225,231,234,236,241,242,254,258,264,270,276,281,289,290],avail_queu:130,avoid:[61,89,91,92,97,243,277],awai:[20,93,129,251,276],await:3,awar:[249,254,255],b0_0:262,b0_1:262,b1_0:262,b1_1:262,b5729002b340:[274,276],b8d17c77a03b37603cd9f89fdcfe0ba726f8ddff6eac63011dee2e959cc316c2:239,bab:205,back:[8,58,64,69,80,81,82,89,90,100,101,128,129,130,187,212,236,253,262,263,275,281,285,286,288],backend:129,backward:[21,128,130,179,214],bad:[128,222,270],badli:92,band:[21,22,27],bang:275,bank:262,bar:[12,129,292],bare:[84,248,254,255,292],base64:[7,130,264,282],base:[1,2,4,6,7,12,20,21,24,31,34,39,55,57,58,59,61,89,101,132,134,136,168,181,182,187,224,243,247,253,256,259,260,262,263,268,275,277,278,282],baselibc:[7,48,93],baselin:133,bash:[2,12,55,59,93],bash_complet:36,bash_profil:[11,58,60,81,83],bashrc:55,basi:[9,19,22,99,270,275,276],basic:[1,14,21,29,30,31,61,89,93,99,101,134,152,182,184,186,193,222,236,239,246,247,264,269,271,273,274,284,286,287],batch:93,batteri:[9,24,31,96,254],baud:[66,130,247,275],baudrat:[135,190,193],bbno055_cli:278,bc_acc_bw:[208,280],bc_acc_rang:[208,280],bc_mask:[208,280],bc_opr_mod:[208,280],bc_placement:208,bc_pwr_mode:[208,280],bc_unit:[208,280],bc_use_ext_xt:280,bcfg:280,bd_addr:20,be9699809a049:71,beacon:[14,245,246,257],bearer:[21,32],becaus:[8,10,12,20,22,26,30,50,87,128,169,179,180,187,190,206,208,211,215,222,224,243,267,269,271,275,277,278,279,282],becom:[22,31,128,249,252],been:[4,10,20,26,36,43,55,58,59,61,77,81,82,84,88,89,90,99,128,129,138,140,152,153,165,173,179,190,193,222,225,244,247,252,256,259,264,268,274,275],befor:[2,4,7,8,12,20,41,50,57,61,80,84,86,88,89,91,92,93,97,99,100,101,128,129,130,140,146,173,174,178,190,192,193,194,199,210,211,214,216,222,223,225,231,232,236,238,243,246,247,248,249,251,254,255,257,258,260,264,267,268,276,281,284,287],begin:[26,89,99,140,148,193,247,250,252,254,255,267,269],beginn:292,behav:[20,30,92,254,255,267],behavior:[59,92,96,161,162,173,242,243,251,253,267,268,290],behaviour:89,behind:[89,100],being:[20,89,90,92,97,99,100,128,129,135,152,179,186,187,188,197,198,222,226,243,250,252,267,275,292],bell:98,belong:[14,90,128,179,253],below:[1,2,4,6,12,18,20,22,23,24,30,43,62,89,92,93,94,98,99,128,130,132,135,153,160,163,179,180,192,208,222,235,243,246,251,253,256,259,260,261,262,263,264,265,267,269,270,271,274,276,277,278,280,284,292],benefit:[10,92,179,225,234,238],best:[89,93,160,199,270],beta:[134,276],better:[128,223],between:[7,12,21,26,27,31,37,46,55,98,100,130,179,186,187,197,199,209,222,224,225,236,238,247,259,264,270,276,278,282],beyond:[89,179],bhd:66,big:[23,61,89,264,270],bigger:222,bin:[2,4,7,11,12,34,35,37,38,43,46,48,50,55,57,58,59,60,61,80,81,82,83,93,168,169,222,225,235,236,239,240,241,242,246,247,250,256,258,259,260,261,262,263,264,267,268,275,276,278,282,285,286,288,289,290],bin_basenam:61,binari:[4,7,11,34,37,39,55,58,60,61,79,81,83,101,132,187,258,275],binutil:4,bit:[7,14,23,25,27,29,57,58,59,66,81,82,86,89,90,99,100,101,128,179,187,188,190,193,206,208,210,211,222,223,241,242,243,246,251,252,253,254,255,268,270,275,276,277,282,289,290],bitbang:188,bitmap:90,bitmask:99,bits0x00:27,bl_rev:278,bla:205,ble:[14,18,19,23,26,30,31,61,64,65,66,67,68,69,70,71,72,73,74,75,76,77,80,81,82,87,89,128,132,133,222,225,236,239,245,247,249,251,252,253,257,273,274,275,279,281,284,292],ble_:251,ble_addr_t:[254,255],ble_addr_type_publ:252,ble_app:[246,254,255],ble_app_advertis:[254,255],ble_app_on_sync:[254,255],ble_app_set_addr:[254,255],ble_att:[76,236,251],ble_att_err_attr_not_found:20,ble_att_err_attr_not_long:20,ble_att_err_insufficient_authen:20,ble_att_err_insufficient_author:20,ble_att_err_insufficient_enc:20,ble_att_err_insufficient_key_sz:20,ble_att_err_insufficient_r:[20,274,276],ble_att_err_invalid_attr_value_len:[20,251],ble_att_err_invalid_handl:20,ble_att_err_invalid_offset:20,ble_att_err_invalid_pdu:20,ble_att_err_prepare_queue_ful:20,ble_att_err_read_not_permit:20,ble_att_err_req_not_support:20,ble_att_err_unlik:[20,274,276],ble_att_err_unsupported_group:20,ble_att_err_write_not_permit:20,ble_att_svr_entry_pool:73,ble_att_svr_prep_entry_pool:73,ble_eddystone_set_adv_data_uid:254,ble_eddystone_set_adv_data_url:254,ble_eddystone_url_scheme_http:254,ble_eddystone_url_suffix_org:254,ble_err_acl_conn_exist:20,ble_err_auth_fail:20,ble_err_chan_class:20,ble_err_cmd_disallow:20,ble_err_coarse_clk_adj:20,ble_err_conn_accept_tmo:20,ble_err_conn_establish:20,ble_err_conn_limit:20,ble_err_conn_parm:20,ble_err_conn_rej_bd_addr:20,ble_err_conn_rej_channel:20,ble_err_conn_rej_resourc:20,ble_err_conn_rej_secur:20,ble_err_conn_spvn_tmo:20,ble_err_conn_term_loc:20,ble_err_conn_term_m:20,ble_err_ctlr_busi:20,ble_err_diff_trans_col:20,ble_err_dir_adv_tmo:20,ble_err_encryption_mod:20,ble_err_host_busy_pair:20,ble_err_hw_fail:20,ble_err_inq_rsp_too_big:20,ble_err_instant_pass:20,ble_err_insufficient_sec:20,ble_err_inv_hci_cmd_parm:20,ble_err_inv_lmp_ll_parm:20,ble_err_link_key_chang:20,ble_err_lmp_collis:20,ble_err_lmp_ll_rsp_tmo:20,ble_err_lmp_pdu:20,ble_err_mac_conn_fail:20,ble_err_mem_capac:20,ble_err_no_pair:20,ble_err_no_role_chang:20,ble_err_page_tmo:20,ble_err_parm_out_of_rang:20,ble_err_pending_role_sw:20,ble_err_pinkey_miss:20,ble_err_qos_parm:20,ble_err_qos_reject:20,ble_err_rd_conn_term_pwroff:20,ble_err_rd_conn_term_resrc:20,ble_err_rem_user_conn_term:20,ble_err_repeated_attempt:20,ble_err_reserved_slot:20,ble_err_role_sw_fail:20,ble_err_sco_air_mod:20,ble_err_sco_itvl:20,ble_err_sco_offset:20,ble_err_sec_simple_pair:20,ble_err_synch_conn_limit:20,ble_err_unit_key_pair:20,ble_err_unk_conn_id:20,ble_err_unk_lmp:20,ble_err_unknown_hci_cmd:20,ble_err_unspecifi:20,ble_err_unsupp_lmp_ll_parm:20,ble_err_unsupp_qo:20,ble_err_unsupp_rem_featur:20,ble_err_unsupport:20,ble_ga:253,ble_gap:76,ble_gap_adv_param:[254,255],ble_gap_adv_set_field:249,ble_gap_adv_start:[249,252,254,255],ble_gap_chr_uuid16_appear:[251,253],ble_gap_chr_uuid16_device_nam:[251,253],ble_gap_chr_uuid16_periph_pref_conn_param:251,ble_gap_chr_uuid16_periph_priv_flag:251,ble_gap_chr_uuid16_reconnect_addr:251,ble_gap_conn_desc:252,ble_gap_conn_find:252,ble_gap_conn_fn:249,ble_gap_conn_mode_und:[249,252],ble_gap_disc_mode_gen:[249,252],ble_gap_ev:252,ble_gap_event_conn_upd:252,ble_gap_event_connect:252,ble_gap_event_disconnect:252,ble_gap_event_enc_chang:252,ble_gap_event_fn:[254,255],ble_gap_event_subscrib:252,ble_gap_svc_uuid16:[251,253],ble_gap_upd:73,ble_gatt:76,ble_gatt_access_ctxt:[251,274,276],ble_gatt_access_op_read_chr:[251,274,276],ble_gatt_access_op_write_chr:[251,274,276],ble_gatt_chr_def:[251,253,274],ble_gatt_chr_f_notifi:274,ble_gatt_chr_f_read:[251,253,274],ble_gatt_chr_f_read_enc:274,ble_gatt_chr_f_writ:274,ble_gatt_chr_f_write_enc:274,ble_gatt_register_fn:253,ble_gatt_svc_def:[251,253,274],ble_gatt_svc_type_primari:[251,253,274],ble_gattc:76,ble_gattc_proc_pool:73,ble_gatts_chr_upd:[274,276],ble_gatts_clt_cfg_pool:73,ble_gatts_find_chr:[274,276],ble_gatts_register_svc:253,ble_h:[14,15,16,17,19,20,23,26,76,254,255,276],ble_hci_ram_evt_hi_pool:73,ble_hci_ram_evt_lo_pool:73,ble_hci_uart_baud:247,ble_hs_:253,ble_hs_adv_field:[249,254],ble_hs_att_err:20,ble_hs_cfg:[26,254,255],ble_hs_conn_pool:73,ble_hs_eagain:20,ble_hs_ealreadi:20,ble_hs_eapp:20,ble_hs_eauthen:20,ble_hs_eauthor:20,ble_hs_ebaddata:20,ble_hs_ebusi:20,ble_hs_econtrol:20,ble_hs_edon:20,ble_hs_eencrypt:20,ble_hs_eencrypt_key_sz:20,ble_hs_einv:20,ble_hs_emsgs:20,ble_hs_eno:20,ble_hs_enoaddr:20,ble_hs_enomem:20,ble_hs_enomem_evt:20,ble_hs_enotconn:20,ble_hs_enotsup:20,ble_hs_enotsync:20,ble_hs_eo:20,ble_hs_ereject:20,ble_hs_erol:20,ble_hs_err_sm_peer_bas:20,ble_hs_err_sm_us_bas:20,ble_hs_estore_cap:20,ble_hs_estore_fail:20,ble_hs_etimeout:20,ble_hs_etimeout_hci:20,ble_hs_eunknown:20,ble_hs_ev_tx_notif:87,ble_hs_event_tx_notifi:87,ble_hs_forev:[252,254,255],ble_hs_hci_err:20,ble_hs_hci_ev_pool:73,ble_hs_id:23,ble_hs_id_gen_rnd:[23,254,255],ble_hs_id_set_rnd:[19,23,254,255],ble_hs_l2c_err:20,ble_hs_reset_fn:26,ble_hs_sm_peer_err:20,ble_hs_sm_us_err:20,ble_hs_sync_fn:26,ble_ibeacon_set_adv_data:255,ble_l2cap:76,ble_l2cap_chan_pool:73,ble_l2cap_sig_err_cmd_not_understood:20,ble_l2cap_sig_err_invalid_cid:20,ble_l2cap_sig_err_mtu_exceed:20,ble_l2cap_sig_proc_pool:73,ble_ll:[76,77,275],ble_ll_cfg_feat_le_encrypt:222,ble_ll_conn:76,ble_ll_prio:225,ble_lp_clock:24,ble_max_connect:[277,279],ble_mesh_dev_uuid:32,ble_mesh_pb_gatt:32,ble_own:[254,255],ble_own_addr_random:[254,255],ble_phi:76,ble_prph:275,ble_public_dev_addr:23,ble_rigado:47,ble_role_broadcast:279,ble_role_peripher:279,ble_sm_err_alreadi:20,ble_sm_err_authreq:20,ble_sm_err_cmd_not_supp:20,ble_sm_err_confirm_mismatch:20,ble_sm_err_cross_tran:20,ble_sm_err_dhkei:20,ble_sm_err_enc_key_sz:20,ble_sm_err_inv:20,ble_sm_err_numcmp:20,ble_sm_err_oob:20,ble_sm_err_pair_not_supp:20,ble_sm_err_passkei:20,ble_sm_err_rep:20,ble_sm_err_unspecifi:20,ble_sm_legaci:222,ble_tgt:[246,254,255],ble_uu:253,ble_uuid128_init:[274,276],ble_uuid128_t:[274,276],ble_uuid16:[251,253],ble_uuid16_declar:[274,276],ble_uuid:276,ble_uuid_128_to_16:251,ble_uuid_u16:[274,276],ble_xtal_settle_tim:24,bleadc:276,blecent:[7,61],blehci:[7,61],blehciproj:247,blehostd:66,blemesh:[21,32],blenano:53,bleprph:[7,21,61,66,222,239,242,248,249,250,251,252,253,274,275,276,277,290],bleprph_advertis:[249,252],bleprph_appear:251,bleprph_device_nam:[249,251],bleprph_log:[249,252,274,276],bleprph_oic:[7,61,281],bleprph_oic_sensor:277,bleprph_on_connect:249,bleprph_pref_conn_param:251,bleprph_print_conn_desc:252,bleprph_privacy_flag:251,bleprph_reconnect_addr:251,blesplit:[7,61],bletest:[7,61],bletini:[7,21,37,38,45,46,50,61,71,236,247,250],bletiny_chr_pool:73,bletiny_dsc_pool:73,bletiny_svc_pool:73,bletoh:89,bleuart:[7,61],blink:[1,7,61,93,99,238,240,243,256,257,259,260,261,262,263,275,276,292],blink_nord:[242,290],blink_nrf:275,blink_primo:275,blink_rigado:47,blinki:[1,12,34,43,44,48,55,61,93,241,242,243,246,247,264,268,275,276,284,285,286,288,289,290,292],blinky_callout:258,blinky_primo:275,blinky_sim:61,blksize:90,blksz:[73,286],blob:[20,183],block:[20,29,73,86,87,89,90,98,134,140,143,173,174,175,176,177,187,190,192,193,238,275,286],block_addr:90,block_siz:90,blocks_siz:90,blue:263,bluetooth:[1,9,20,22,23,24,27,29,32,89,222,239,248,249,254,255,257,275,276,292],bmd300eval:[48,53,261,276],bmd:[261,276],bno055:[207,208,277,279,280],bno055_0:[207,278,280],bno055_acc_cfg_bw_125hz:280,bno055_acc_cfg_rng_16g:280,bno055_acc_unit_ms2:280,bno055_angrate_unit_dp:280,bno055_cfg:[208,280],bno055_cli:[278,279],bno055_config:[208,280],bno055_default_cfg:208,bno055_do_format_android:280,bno055_err:208,bno055_euler_unit_deg:280,bno055_get_chip_id:208,bno055_id:208,bno055_info:208,bno055_init:[207,208],bno055_ofb:[207,277,278,279],bno055_opr_mode_ndof:280,bno055_pwr_mode_norm:280,bno055_sensor_get_config:208,bno055_sensor_read:208,bno055_shel:278,bno055_shell_init:278,bno055_stat_sect:208,bno055_temp_unit_degc:280,board:[1,2,4,5,7,8,10,12,23,24,30,39,42,47,53,55,57,58,59,61,92,93,134,181,182,187,208,209,213,222,224,225,235,236,238,239,240,241,242,243,247,250,254,255,257,258,274,275,280,281,282,284,287,289,290,292],bodi:[128,280],bold:[235,244],bond:[22,27,29,30,250],bondabl:27,bone:[84,248,254,255,292],bookkeep:140,bool:[90,199],boot:[7,10,43,61,93,100,101,130,195,235,236,239,247,256,259,260,261,262,263,264,268,275,276,278,282,285,286,288],boot_boot_serial_test:7,boot_bootutil:222,boot_build_statu:128,boot_build_status_on:128,boot_clear_statu:128,boot_copy_area:128,boot_copy_imag:128,boot_erase_area:128,boot_fill_slot:128,boot_find_image_area_idx:128,boot_find_image_part:128,boot_find_image_slot:128,boot_go:128,boot_img_mag:128,boot_init_flash:128,boot_load:93,boot_mag:128,boot_move_area:128,boot_nrf:275,boot_olimex:262,boot_primo:275,boot_read_image_head:128,boot_read_statu:128,boot_select_image_slot:128,boot_seri:[7,130],boot_serial_setup:7,boot_slot_addr:128,boot_slot_to_area_idx:128,boot_swap_area:128,boot_test:7,boot_vect_delete_main:128,boot_vect_delete_test:128,boot_vect_read_main:128,boot_vect_read_on:128,boot_vect_read_test:128,boot_write_statu:128,bootabl:[222,239,285,288],bootload:[1,12,43,47,93,96,101,130,191,195,235,239,243,257,258,275,276,277,279,287],bootutil:[7,101,128,130,256,259,260,261,262,263,264,268,278,285,286,288],bootutil_misc:[7,256,259,260,261,263,278,285,286,288],both:[6,9,11,14,20,22,27,29,39,55,57,58,59,62,89,91,93,98,128,129,131,134,173,179,187,190,199,205,222,224,225,234,256,258,264,267,268,271,276],bottl:[58,81],bottom:[12,93,97,99,250],bound:[89,93,152],boundari:[89,90,93],box:[12,242,290],bps:193,branch:[1,4,7,10,11,55,56,57,59,60,79,80,82,83,128,244,256,268,269,270],branchnam:10,brand:263,bread:276,breadboard:276,breakdown:222,breakout:8,breakpoint:[256,260],breviti:[222,235,286],brew:[3,4,7,11,36,55,58,60,81,83],brick:128,bridg:179,brief:[19,186,254,255,264],briefli:93,bring:[12,93,181,278,281,284],broad:292,broadca:[254,255],broadcast:[14,27,31,249,254,255],brows:[250,259,269],browser:244,bsd:101,bsp:[1,7,24,32,34,37,38,42,43,45,47,50,55,61,62,92,129,134,173,174,176,177,181,185,186,192,193,206,207,208,209,211,222,225,235,238,241,242,246,247,250,256,258,259,260,261,262,263,264,268,275,276,277,278,279,280,282,285,286,288,289,290,292],bsp_arduino_zero:256,bsp_arduino_zero_pro:[256,268],bsp_flash_dev:174,bsp_timer:192,bsppackag:93,bss:[48,93,222],bssnz_t:[274,275,276],btattach:247,btshell:29,buad:66,buf:[129,135,153,154,155,156,160,161,163,164,168,171,199],buf_len:89,buffer:[10,20,89,90,92,96,97,130,134,156,163,169,171,179,187,190,199,205,224,255,276],buffer_len:276,buffer_size_down:[241,289],bug:[4,7,11,160,161,241,242,256,260,282,289,290],bui:276,build:[1,2,3,4,5,6,11,31,32,35,37,38,39,40,41,42,43,44,45,46,47,48,49,50,51,52,53,54,57,58,59,62,80,82,92,93,94,96,128,134,181,187,198,205,209,222,223,224,225,231,238,239,248,249,250,257,267,274,275,284,287,292],build_arduino_blinki:12,build_arduino_boot:12,build_numb:197,build_profil:[1,32,37,38,43,50,53,61,93,222,235,246,247,250,256,259,260,261,262,263,264,268,275,276,277,278,279,282,285,286,288],buildabl:7,builder:244,built:[1,4,7,8,9,21,33,34,38,39,42,43,55,57,58,59,60,61,63,81,82,83,89,128,190,205,222,231,235,236,244,246,247,250,254,255,256,257,258,259,260,261,262,263,264,267,268,274,275,276,277,278,282,285,286,288],bunch:275,bundl:[55,101,152],burn:[254,255],bus:[2,187],buse:[134,181],busi:[20,90,91,243,275],button1_pin:238,button:[2,4,10,12,98,238,256,259],bytes_read:[153,160,163,168,171],bytyp:211,c_ev:84,c_evq:84,c_tick:84,cabl:[236,238,239,243,247,256,257,259,260,261,262,264,268,276,282,284,285,287,288],cach:[58,81,134,173,175,181],cache_large_file_test:267,calcul:[20,29,48,90,100,128,140],calendar:9,call:[6,7,9,11,19,21,23,26,36,61,84,85,86,87,88,89,90,91,92,93,97,98,99,100,101,128,129,130,131,132,134,135,138,140,141,142,143,145,146,150,158,161,165,168,171,172,175,176,178,179,180,183,186,187,189,190,191,192,193,194,196,199,205,206,207,208,210,211,212,214,216,217,220,223,225,227,228,229,230,231,232,233,236,238,243,245,246,249,250,251,252,253,254,255,256,258,264,267,269,275,276,277,278,282,287],callback:[20,26,86,87,89,90,130,140,145,150,186,190,192,193,206,207,208,210,212,225,238,249,251,253,254,255,258,275,282],caller:[89,90,130,140,192,198,199,215,219],callout:[87,92,97,211,258,282],callout_l:238,callout_reset:129,came:247,can:[1,2,3,4,5,6,7,8,9,11,12,19,20,21,22,23,24,27,30,31,33,34,35,42,45,50,55,57,58,59,60,61,62,63,64,66,72,76,80,81,82,83,84,85,86,87,89,90,91,92,93,94,96,97,98,99,101,128,129,130,131,134,135,136,137,140,141,143,145,146,150,151,152,161,165,166,169,171,173,174,176,179,180,181,186,188,189,190,192,193,194,195,199,205,206,207,208,209,210,211,214,215,219,220,221,222,223,224,225,227,228,230,231,234,235,236,238,239,240,241,242,243,244,246,247,249,250,251,252,253,254,255,256,257,258,259,260,261,262,263,264,265,267,268,269,270,274,275,276,277,278,279,280,282,284,285,286,288,289,290,292],cancel:[20,27,84],candid:269,cannot:[4,19,20,71,86,88,91,92,98,128,129,151,169,179,182,190,192,225,236,256,268,269,270,271],capabl:[20,22,27,29,95,130,134,205,222,241,243,258,289],capac:20,captian:81,captur:179,carbon:274,card:[136,151],care:[89,92,99,163,171,254,255,269,270,274],carri:89,cascad:[1,61],cast:[89,90,251],cat:[80,275,276],catastroph:26,categor:93,categori:[10,96],caus:[90,92,98,153,160,161,166,169,179,187,191,224,226,239,241,243,276,289],caveat:128,cb_arg:[150,192,249,253,254,255],cb_func:192,cbmem:[7,205,226],cbmem_buf:205,cbmem_entry_hdr:226,cbmem_init:205,cbmem_read:226,cbmem_test_case_1_walk:226,cbor:[132,133],cborattr:7,cccd:27,ccm:22,cdc:259,cell:22,cellar:[4,6,11,36,58,60,81,83],central:[20,30,248,249,250,252],certain:[1,21,89,90,92,93,134,247,270],certainli:276,cess_op_:251,cfg:[70,171,172,187,190,192,193,207,208,260],cflag:[1,50,61,93],cgi:101,ch_commit:129,ch_export:129,ch_get:129,ch_name:129,ch_set:129,chain:[89,90,199],challeng:265,chanc:[92,99],chang:[1,4,6,7,10,11,19,20,21,22,24,28,30,46,49,50,52,57,61,62,80,89,93,94,128,179,186,190,206,207,214,222,224,225,235,236,238,240,241,242,243,244,247,250,252,254,255,256,260,274,275,276,277,278,279,282,284,289,290],channel:[20,21,29,134,276],channel_map:27,chapter:[2,21,96,132],charact:[130,139,156,159,173,179,193,197,198,199,200,201,202,203,214,219,225,241,253,268,282,289],character:24,characteri:[251,253],characterist:[9,16,17,21,27,28,128,250,253,274,276],check:[4,6,8,11,20,22,55,56,79,84,87,90,99,129,179,199,208,222,224,225,235,239,246,247,248,259,262,264,267,270,275,278,280,287],checkbox:59,checkin:[77,97,99],checkout:[10,80,82,257],checksum:[140,142],child:[90,154,155,156,161,164,179],children:179,chip:[4,96,134,135,181,186,190,191,206,208,256,257,259,260,263,268,269,275,278],chip_id:278,chipset:[134,181,256,268],choic:[2,10,173,247,278],choos:[6,7,10,89,99,101,222,223,236,243,246,249,258,259,261,274,276],chose:223,chosen:[89,93,128,151,179,276],chr:[251,274,276],chr_access:251,chr_val_handl:[274,276],chunk:[10,89],ci40:53,cid:250,circuit:187,circular:[205,224,225],circularli:270,clang:6,clarif:10,clarifi:134,clariti:136,classif:20,clean:[1,11,33,39,50,57,58,59,63,81,159,177,243,264],cleanli:225,clear:[72,84,89,99,128,179],clearli:[8,20],cli:130,click:[2,4,10,12,244,250,254,255,256,259,260,262,288],client:[12,17,18,20,21,27,31,152,180,209,254,274],clk:190,clobber:166,clock:[20,25,86,191,256,260,278],clock_freq:86,clone:[10,11,45,50,55,58,81],close:[2,59,134,152,153,154,155,156,157,160,161,163,164,168,169,170,171,172,193,207,256,259,260,262,263,280],closest:192,cmake:1,cmd:[55,61,93,184,275,278],cmd_len:275,cmd_queue:130,cmd_read_co2:275,cmp:275,cmsi:[2,7,48,93,256,259,260,261,262,263,282],cmsis_nvic:[93,259,260,261,262,263,282],cn4:235,cnt:[73,130,176,177,190,286],co2:[274,275],co2_evq:274,co2_read_ev:274,co2_sns_str:274,co2_sns_typ:274,co2_sns_val:274,co2_stack:274,co2_stack_s:274,co2_task:274,co2_task_handl:274,co2_task_prio:274,coap:[133,209,212,277,281],coars:20,coc:27,code:[1,5,7,9,11,13,18,21,24,26,27,29,55,85,89,90,92,95,96,97,100,101,128,130,132,134,136,139,152,153,154,155,156,157,159,160,161,163,164,166,168,169,170,171,172,176,177,178,179,180,181,182,186,187,190,192,193,195,205,207,208,209,222,225,226,227,228,230,231,232,236,238,243,248,249,251,252,253,256,257,258,264,266,268,269,275,276,277,280,281,282,284,286,287,292],codebas:[256,268],coded_interval_max:27,coded_interval_min:27,coded_lat:27,coded_max_conn_event_len:27,coded_min_conn_event_len:27,coded_scan_interv:27,coded_scan_window:27,coded_timeout:27,codepag:151,coding_standard:7,coexist:128,collect:[1,7,43,55,61,89,90,132,140,180,199,222,235,269],collis:20,colon:66,color:240,column:19,com11:8,com1:66,com3:[8,258,268,278,285,288],com6:8,com:[8,10,11,12,33,55,57,58,59,63,80,81,82,101,183,235,247,258,268,269,271,278,285,286,288],combin:[1,20,22,26,43,61,92,93,187,246,254,255,269,270],combo:222,come:[3,21,30,55,61,93,101,130,134,205,256,262,263,268,275,276,288],comm:[235,257],comma:[51,66],comman:220,command:[1,2,4,7,8,10,11,20,30,34,35,36,37,38,40,41,42,44,45,46,47,48,49,51,52,53,54,57,58,59,60,61,67,68,70,71,72,75,76,78,80,81,82,83,93,96,128,131,133,136,138,187,195,196,205,209,215,219,220,221,222,223,224,225,231,235,237,239,240,241,242,243,246,254,255,256,258,259,260,261,262,263,264,265,267,268,269,271,272,276,277,278,279,280,282,285,288,289,290],comment:[3,10,93,234,292],commerci:275,commit:[10,11],common:[55,61,87,89,96,98,99,134,135,181,186,208,209,222,253,260],commonli:[98,190,254],commun:[9,21,26,27,31,66,78,130,132,136,187,190,206,207,208,235,238,239,240,243,247,249,252,257,264,268,269,275,276,278,282,285,286,287,288,292],compani:29,compar:[10,20,89,160,243,259,260,261,264,272,276],comparison:[20,22,89,100],compat:[4,10,21,55,128,130,135,214,215,222,241,256,264,268,278,280,282,289],compens:100,compil:[1,4,5,6,7,8,11,20,34,47,53,55,58,61,81,89,93,96,101,134,214,223,225,231,234,235,236,238,246,256,259,260,261,262,263,264,268,275,276,277,278,282,285,286,288],complaint:21,complementari:31,complet:[9,12,20,22,27,29,30,33,55,59,63,93,95,96,99,128,130,140,154,155,156,161,164,179,181,187,190,193,205,222,229,233,234,238,243,247,249,254,255,260,269,276,277,280,281,282,285,286,288],completion_cb:130,complex:[9,31,92,93,134,181,243,245],compli:21,complianc:[275,276],compliant:21,complic:[55,92,222],compon:[1,7,12,18,39,48,55,57,58,59,61,85,93,96,129,134,181,187,190,222,223,236,238,239,247,254,255,257,268,275,284,287],compos:[39,57,58,59,234],composit:199,comprehens:234,compress:[55,81,173,254],compris:[7,128,173,174],comput:[3,4,6,8,12,31,56,58,59,79,81,130,142,151,239,243,246,247,256,257,259,260,261,262,263,277,279,284,285,287,288],concept:[12,22,89,92,160,214,225,239,243,245,246,248,256,257,268,284,287],concern:[3,89,179],concis:132,conclud:[254,255,276],concurr:[1,34,35,37,38,39,40,41,42,43,44,45,46,47,48,49,50,51,52,53,54,57,58,59,62,84,88,248,249],condit:[4,20,128,179,187,207,214,224,226,267,275,276],condition:[55,207,224,225,278],conduct:[128,132],conf:264,conf_export_tgt:129,conf_fcb_dst:129,conf_fcb_src:129,conf_file_dst:129,conf_file_src:129,conf_get_valu:129,conf_handl:129,conf_init:232,conf_int8:129,conf_load:129,conf_regist:[129,226],conf_sav:129,conf_save_on:129,conf_set_valu:129,conf_str_from_valu:129,conf_value_set:129,confidenti:22,config:[1,7,32,50,61,62,64,78,80,81,82,131,135,151,153,157,160,163,170,192,224,225,232,236,246,275,276,278],config_:207,config__sensor:207,config_bno055_sensor:[207,280],config_cli:129,config_fcb:[129,224],config_fcb_flash_area:[224,225],config_lis2dh12_sensor:207,config_newtmgr:[50,236],config_nff:[129,152,224],config_pkg_init:225,config_test_al:232,config_test_handl:226,config_test_insert:[226,227],configur:[6,7,9,19,20,25,26,31,32,50,55,57,58,59,61,62,86,90,92,93,94,96,128,130,132,134,152,173,175,179,181,182,186,187,190,192,193,194,209,210,212,222,238,241,242,243,246,249,253,256,259,262,263,264,265,271,276,278,281,282,284,286,289,290],configuraton:151,confirm:[8,20,27,71,128,222,239,264,285,288],confirmbe9699809a049:71,conflict:[61,224,270],confluenc:10,confus:[269,276],congratul:[7,235,250,274,275,276],conjunct:[31,210],conn:[27,28,30,64,65,67,68,69,70,71,72,73,74,75,76,77,78,80,81,82,239,252,254,255,285,286,288],conn_handl:[20,250,251,252,274,276],conn_interval_max:29,conn_interval_min:29,conn_itvl:[30,250],conn_lat:[30,250],conn_mod:252,conn_profil:[65,66,67,68,69,70,71,72,73,74,75,76,77],conn_upd:252,connect:[4,7,8,9,10,12,15,20,21,22,24,26,28,29,31,38,42,43,55,64,65,66,67,68,69,70,71,72,73,74,75,76,77,78,80,81,82,96,130,132,133,134,181,186,187,190,191,222,235,238,248,249,250,251,252,254,255,257,274,275,284,287],connect_don:268,connectable_mod:249,connection_profil:71,connectionless:27,connector:[4,236,247,259,262,264,288],connextra:10,connintervalmax:29,connintervalmin:29,connstr:[66,239,285,286,288],conntyp:10,consecut:97,consequ:[20,128,222],conserv:[9,89,96],consid:[21,62,89,92,98,142,187,226,253,269],consider:226,consist:[1,21,31,61,98,99,128,129,132,134,162,179,190,222,224,225,231,253],consol:[1,7,8,12,26,55,61,96,101,129,137,154,155,156,161,164,171,193,205,218,225,238,246,247,250,254,255,257,267,275,276,286],console_append_char_cb:130,console_blocking_mod:130,console_compat:130,console_echo:130,console_handle_char:130,console_init:130,console_input:130,console_is_init:130,console_is_midlin:130,console_max_input_len:130,console_non_blocking_mod:130,console_out:130,console_pkg_init:225,console_printf:[20,26,130,153,154,155,156,160,161,163,164,168,171,226,274,275,276,282],console_prompt:275,console_read:130,console_rtt:[130,241,282,289],console_rx_cb:130,console_set_completion_cb:130,console_set_queu:130,console_tick:[130,275],console_uart:[130,241,282,289],console_uart_baud:130,console_uart_dev:130,console_uart_flow_control:130,console_uart_tx_buf_s:130,console_writ:[130,226],consolid:179,consortium:132,constant:190,constantli:[249,268,276,292],constitu:[43,179],constrain:[9,55,133,265],constraint:256,construct:[11,89,98],consult:[152,181],consum:[87,98,193],consumpt:22,contact:[94,95,235],contain:[1,3,7,11,29,31,34,50,55,61,84,89,90,93,95,96,98,99,100,128,130,132,134,137,140,153,156,157,160,163,166,167,168,170,176,179,182,186,193,195,197,198,199,210,218,222,223,225,226,229,231,234,246,247,249,251,253,254,255,264,267,269,270,278,292],content:[12,49,61,80,89,93,128,140,141,142,154,155,156,161,164,171,179,192,199,222,232,235,243,249,253,254,255,262,264,267,270,271,278,280],context:[55,77,85,86,87,92,99,130,134,139,190,192,214,216,225,236,238,252,258],contigu:[89,128,140,179],continu:[6,93,98,129,179,214,222,236,238,240,241,243,244,247,256,257,262,268,276,279,280,281,282,284,286,287,289],contrast:225,contribut:[13,22,57,58,59,80,81,82,245,267,284],contributor:[181,275,276],control:[8,9,18,19,20,21,22,23,25,26,29,31,55,66,96,130,134,140,160,173,181,183,190,193,205,208,214,225,246,260,262,269,270,275,276,281],contruct:250,convei:89,conveni:[12,20,89,129,171,179,198,226],convent:[264,267,278,282],convers:[101,134,251],convert:[1,8,20,71,84,86,89,100,129,134,174,176,177,179,190,199,225,251,253,275,276],coordin:[277,279],copi:[1,4,45,49,50,62,80,82,89,94,95,128,140,179,199,207,222,223,239,241,242,249,252,256,275,276,280,282,289,290],copy_don:128,copyright:[4,241,242,256,262,275,276,282,289,290],core:[1,6,7,12,21,29,32,37,38,43,48,50,51,53,55,61,62,71,88,93,95,97,129,132,134,152,181,183,222,223,235,241,242,243,246,247,248,249,250,256,257,258,259,260,261,262,263,264,267,268,269,270,275,276,277,278,279,282,284,285,286,287,288,289,290,292],core_cminstr:260,core_o:130,core_path:61,coreconvert:71,coredownload:71,coredump:[7,182],coredump_flash_area:225,coreeras:71,corelist:71,corner:262,corp:[2,256],correct:[1,2,4,41,90,93,100,128,173,222,225,243,247,260,261,262,264,267,276,278],correctli:[2,89,240,247,256,260,267,276,277],correspo:253,correspond:[12,20,86,89,90,93,128,162,175,179,180,205,206,249,251,254,255,270,276],corrupt:[90,167,179],corrupt_block_test:267,corrupt_scratch_test:267,cortex:[4,101,259,261,264,268,276,282],cortex_m0:61,cortex_m4:[61,93,259,260,261,262,263,264,282],cortex_m:256,cost:9,could:[20,89,98,179,197,251,275],couldn:[226,249,275],count:[55,81,89,98,99,128,129,179],counter:[85,89,223,264],countri:21,coupl:[1,262,275,276],cours:274,cover:[8,61,134,179,225,234,243,253],cpha:190,cpol:190,cpptool:12,cpu:[85,93,95,134,181,182,189,243,256,260],cputim:[24,86,278,282],cputime_geq:86,cputime_gt:86,cputime_leq:86,cputime_lt:86,crank:276,crash:[64,78,80,81,82,97,128,131,191,193,236],crash_test:[7,131,236],crash_test_newtmgr:236,crc16:179,crc:[7,130,136,275],creat:[1,2,3,4,5,6,8,10,11,12,22,27,32,34,39,41,43,44,45,46,47,50,55,57,58,59,61,62,66,71,80,81,82,87,90,91,92,95,97,98,99,101,130,134,143,157,159,160,161,166,169,170,172,173,176,179,205,206,208,209,211,212,216,222,223,224,225,231,233,238,240,243,248,253,257,258,269,271,274,280,281,284,287,292],create_arduino_blinki:12,create_mbuf_pool:89,create_path:159,creation:[47,134,235,264,276],creator:[206,207,208,209,211,277,278,280,282],credenti:271,criteria:20,critic:3,cross:[5,6,7,9,96],crt0:48,crti:48,crtn:48,crw:8,crypto:[7,256,259,261,263,268,285,286,288],crypto_mbedtl:222,cryptograph:[22,128],cryptographi:22,crystal:25,csrk:27,css:244,cssv6:29,csw:[77,275,285,288],ctlr_name:66,ctlr_path:66,ctrl:[12,241,246,275,278,289],ctxt:[251,252,274,276],cur_ind:252,cur_notifi:252,curi:[250,252],curiou:[3,244],curl:[11,58],curn:[250,252],curr:268,currantlab:[81,82],current:[11,24,27,31,39,40,41,44,45,46,50,51,57,58,59,60,71,81,82,83,85,86,89,90,91,92,93,97,98,99,100,128,129,130,134,135,136,137,139,140,151,152,157,158,159,160,170,172,179,186,187,190,192,195,206,214,223,224,226,229,233,235,236,239,243,254,256,257,260,262,264,265,269,270,272,278,282],custom:[23,71,90,162,180,182,205,225],cvs:[241,242,256,262,282,289,290],cwd:12,cycl:[19,21,31,179],cylind:276,daemon:[2,247],dai:[100,214],dap:[2,256,259,263],darwin10:[241,242,256,282,289,290],darwin:6,data:[9,14,20,21,27,28,30,31,43,48,64,69,80,81,82,84,86,89,90,92,93,96,99,128,129,130,132,133,141,142,143,144,145,146,150,153,157,159,160,162,163,168,169,170,171,172,175,178,188,190,193,204,207,209,212,213,217,219,222,225,242,243,251,252,254,255,274,275,276,284,290,292],data_len:275,data_mod:190,data_ord:190,databas:28,databit:193,databuf:[89,282],datagram:217,datalen:27,datasheet:93,date:[11,68,151,264,267,275],datetim:[7,64,78,80,81,82,130,131,133,236,267],datetime_pars:267,daunt:249,daylight:100,dbm:[21,27,29],ddress:25,deactiv:222,deal:[89,92,93,134],deb:[57,60,80,83],debian:[4,6],debug:[1,2,4,5,6,7,39,43,47,50,55,57,58,59,62,94,208,209,224,235,239,241,242,246,247,256,258,259,260,261,262,263,268,275,276,277,278,279,282,285,286,288,289,290],debug_arduino_blinki:12,debug_arduinoblinki:12,debugg:[5,38,39,55,57,58,59,61,191,241,242,256,259,260,262,263,264,288,289,290],dec:[48,222],decemb:22,decid:[55,85,96,243,275],decim:[22,187],decis:187,declar:[12,91,99,129,183,192,207,219,228,230,238,267,269,280,282],decod:[214,217],decompress:254,dedic:[87,93,96,214,222,236,238,241,242,251,289,290],deep:182,deeper:[89,235,264,276],def:[7,207,224,225,276,282],defaultdevic:82,defin:[1,6,19,20,21,24,27,28,29,31,34,42,43,47,50,53,61,84,86,87,89,90,92,97,99,128,129,131,133,134,176,177,182,183,185,186,190,205,206,207,209,210,211,212,213,214,220,222,224,225,226,227,229,231,235,238,241,243,245,247,249,251,257,264,267,269,270,274,275,276,277,278,281,282,285,287,288,289],defininig:31,defininit:198,definit:[1,12,29,35,37,42,50,61,84,89,90,93,128,214,223,231,247,251,253,269,274,275,276],defint:[89,224],del:27,delai:[26,86,100,192,240,243,264],deleg:222,delet:[1,6,10,12,27,35,39,45,49,50,55,57,58,59,61,62,153,169,173,179,240,265,274,280,282],delimit:50,deliv:[84,151],delta:[55,81,235],demo:274,demonstr:[20,26,89,159,166,171,264,278,282],denot:89,dep:[1,50,55,61,62,93,130,135,136,151,152,180,181,205,207,214,223,225,236,238,246,258,267,275,276,277,282],depend:[1,4,6,8,20,22,24,27,39,41,49,50,52,55,57,58,59,62,66,84,89,95,101,128,130,151,152,160,179,186,187,190,200,205,207,214,223,225,226,229,231,233,243,246,256,267,268,269,272,275,276,278,285,287,288],depict:181,deploi:[43,222,258],deploy:31,deprec:225,depth:[4,95],dequeu:[87,238],deriv:[20,179],desc:[176,177,252],descend:[128,169],describ:[1,2,7,10,11,12,24,28,33,63,90,92,93,94,96,99,128,132,140,146,151,173,179,186,188,190,199,204,206,207,208,214,222,224,225,231,235,236,244,246,248,253,254,260,263,264,269,275,276,277,278,280,284],descript:[1,7,10,19,27,28,30,55,61,89,93,94,95,129,136,139,141,142,143,144,145,146,147,148,149,150,153,154,155,156,157,158,159,160,161,163,164,166,167,168,169,170,171,172,176,177,197,198,200,201,202,203,204,205,206,207,210,211,215,216,217,218,219,220,221,223,224,225,226,227,228,229,230,235,242,264,265,267,269,270,275,276,290],descriptor:[16,17,27,28,61,160,161,174,176,177,179,251],design:[21,22,23,55,96,97,100,128,173,179,214,222,233,243,253,267],desir:[86,89,98,192,207,267,272],desktop:10,destin:[4,31,89,156,163,166,171,179,187,198,205],detail:[1,10,12,21,22,29,55,92,99,128,129,152,173,187,190,206,207,208,210,211,222,235,236,241,242,246,249,251,253,254,255,256,264,269,282,289,290],detect:[20,55,90,140,152,173,176,177,191,217,224,225,247],determin:[20,87,89,90,99,128,140,179,192,214,222,225,234,249,252,269,280],dev:[1,2,3,4,7,8,10,11,12,48,61,66,82,130,134,135,207,208,225,234,235,239,240,246,247,250,256,258,259,260,261,262,263,264,268,269,270,271,275,276,277,278,280,282,285,286,288,292],dev_found:247,develop:[3,5,6,7,8,9,13,20,55,59,61,82,89,90,92,94,95,96,99,132,134,209,212,214,225,234,239,241,242,243,247,248,251,254,256,257,259,262,263,269,270,274,275,276,281,284,288,289,290,292],devic:[3,4,8,9,14,19,20,21,22,25,28,29,31,32,43,55,64,65,66,67,68,69,70,71,72,73,74,75,76,77,78,80,81,82,96,128,130,132,133,134,135,136,152,174,181,183,186,187,190,209,210,211,212,222,223,224,225,236,241,242,245,246,248,249,250,251,253,254,255,256,258,259,260,261,262,263,264,268,274,276,281,282,285,286,287,288,289,290,292],device_id:183,deviceaddr:23,deviceaddrtyp:23,dflt:199,dhcp:268,dhkei:20,diag:193,diagram:[132,243,260,262],dialog:[12,59,242,290],dictat:[11,62],did:[10,222],diff:275,differ:[4,6,7,8,11,12,20,24,27,30,45,55,57,80,84,89,91,92,93,94,95,96,99,134,173,181,186,193,207,222,223,224,225,228,236,238,239,242,243,246,247,258,259,260,262,265,267,268,269,270,272,274,278,280,282,288,290],differenti:[89,269],difficult:[21,95,128,224],dig:[7,248],digit:[22,134,186,276],dioxid:274,dir:[27,136,152,154,155,156,161,162,164],direct:[10,20,27,187,214,223,270],direct_addr:[254,255],directli:[7,11,14,18,36,152,192,193,205,222,225,254,256,265,267,268,277,280],directori:[1,4,6,7,8,10,11,12,34,35,37,41,43,45,50,55,57,59,60,80,82,83,88,93,94,95,129,134,136,154,155,156,159,160,161,164,165,166,167,169,171,172,189,191,231,235,240,242,246,247,256,257,259,260,261,262,263,267,268,269,270,275,276,277,278,282,284,285,287,288,290,292],dirent:[136,154,155,156,161,162,164],dirnam:[154,155,156,161,164],dirti:235,disabl:[6,20,22,24,30,86,130,151,179,186,190,193,205,207,208,214,222,224,225,236,241,252,265,268,277,278,279,282,289],disable_auto_eras:135,disallow:[20,173],disbl:214,disc_mod:252,discard:[179,268],disciplin:247,disclaim:[7,11,55,246],disconnec:27,disconnect:[27,252],discontigu:128,discov:[22,27,28,247],discover:[27,29,133,212,249,281],discoverable_mod:249,discoveri:[28,132,134,136,247,252,257],discret:[173,174],discuss:[10,89,94,207,222,249,278],disjoint:20,disk:[7,128,140,152,153,167,169,173,174],disk_nam:152,disk_op:136,disk_regist:[136,152],dispatch:[92,225,238],displai:[1,6,22,27,34,35,37,38,39,40,41,42,43,44,45,46,47,48,49,50,51,52,53,54,57,58,59,61,62,64,66,69,71,72,73,76,77,80,81,82,134,181,225,247,262,264,275,277,279,284,285,288],displayonli:27,displayyesno:27,dist:[57,80],distanc:[21,223],distinct:22,distribut:[1,4,6,20,21,27,55,101,128,269,275,276],distro:6,div0:67,dive:89,divid:[18,20,67,129,131,173,174,222],dle:27,dll:[259,261,264,276],dm00063382:235,dma:134,dndebug:50,dnrf52:93,do_task:223,doc:[4,6,7,10,23,33,63,244,256,257,260],docker:[3,7,256,292],dockertest:2,document:[1,4,8,12,14,18,20,23,25,59,62,64,93,97,101,137,151,152,162,180,181,183,222,231,235,239,241,242,243,248,251,253,254,255,256,259,261,267,268,269,278,282,285,286,289,290],doe:[7,20,22,35,50,61,66,71,87,89,90,92,93,94,99,100,128,130,132,134,140,157,161,169,170,173,174,176,179,187,190,195,205,207,208,210,220,223,224,225,236,238,239,243,246,249,256,259,260,261,263,264,265,271,282,287],doesn:[8,10,20,32,97,128,136,157,169,170,222,226,240,243,246,247,249],doing:[88,100,134,243,251,258,275],domain:2,don:[1,10,31,34,35,37,38,39,40,41,42,43,44,45,46,47,48,49,50,51,52,53,54,57,58,59,62,87,89,129,137,140,163,171,235,251,253,254,255,269,275,276],done:[6,7,8,23,25,55,81,91,92,93,100,128,130,140,141,160,161,175,194,195,211,227,228,230,235,236,239,241,242,243,247,253,254,255,256,259,260,261,264,268,276,282,289,290],dont:[241,289],doorbel:55,dop:152,doubl:[2,199,262],doubli:179,doubt:253,down:[1,12,61,80,82,186,222,236,260,262,288],downgrad:[6,7],download:[1,2,4,7,10,12,29,39,41,42,55,58,59,60,70,71,81,82,83,152,195,241,242,244,246,247,256,259,260,261,262,263,267,268,271,275,282,284,285,286,288,289,290],doxygen:[4,7,88,129,256,260],doxygengroup:[88,129],dpidr:263,dpkg:[57,60,80,83],drag:20,drain:24,draw:24,drive:[9,61,100,134,187],driver:[7,55,135,136,152,181,185,186,188,190,192,193,207,209,211,223,241,246,256,259,260,261,262,263,268,278,282,288,289],drop:[10,12,26,179,193,260,262,288],dsc:251,dsimmon:275,dsize:89,dst:[45,50,70,89,171,184,198],dsym:[55,61],dtest:50,due:[20,90,128,135,140,151,191,256,260,262],dummi:179,dump:[129,241,289],dumpreg:278,duplex:21,duplic:[27,89],durat:[19,27,30,100,251,278],duration_m:[254,255],dure:[20,22,71,85,93,97,99,128,130,161,179,196,207,222,225,231,243,246,251,258,277,280],duti:[21,31],dwarf:61,dylib:4,dynam:[88,90],e407:[262,288],e407_:262,e407_devboard:[53,262,288],e407_devboard_download:262,e407_sch:288,e761d2af:[274,276],e_gatt:253,eabi:[4,7,12,93,101,241,242,256,282,289,290],each:[1,2,10,11,12,19,20,21,22,23,28,32,43,48,49,50,61,62,64,66,73,77,87,89,90,92,93,98,100,128,130,134,154,155,156,161,162,164,166,173,174,175,179,181,186,205,206,208,209,210,211,212,214,218,219,222,223,225,236,238,243,251,252,253,254,255,256,267,269,278,280,281,282,292],ead:152,eager:3,earlier:[10,30,57,58,59,80,81,82,169,241,251,254,255,274,275,276,289],eas:135,easi:[1,2,3,8,9,134,181,187,223,224,226,244,259,276,277],easier:[24,93,275],easiest:275,easili:[9,171,209,225,282],east:100,eavesdropp:19,ecdsa256:128,ecdsa:128,echo:[12,60,64,78,80,81,82,83,130,131,133,236,268,275,285,286,288],echocommand:12,eclips:12,ectabl:[254,255],edbg:[2,256],eddyston:[27,257],eddystone_url:[27,29],edg:186,edit:[7,94,151,235,240,264,265,269,280],editign:244,editor:[59,61,235,240,260],ediv:27,edr:[20,29,247],edu:[241,259,289],ee02:264,eeirili:274,eeprom:135,effect:[98,100,129,152,173,174],effici:[21,31,89,90,179,256],eid:254,eight:[132,168],einval:86,eir:29,eir_len:247,either:[1,4,6,11,21,27,29,30,57,59,61,80,84,85,87,89,90,99,129,130,131,137,140,166,186,187,190,191,222,225,226,229,230,236,254,255,264,275,276,284],elaps:[20,86,100],electron:292,element:[39,53,55,57,58,59,89,90,99,128,129,139,140,141,142,145,147,148,179,199,214,243],elev:91,elf:[7,12,34,38,48,55,61,71,222,235,236,241,242,246,247,250,256,258,259,260,261,262,263,264,267,268,275,276,278,282,285,286,288,289,290],elfifi:71,elicit:222,els:[23,85,97,128,154,155,156,161,164,179,208,222,241,274,275,276,289],elsewher:[248,251,269],emac:275,email:[3,234,292],emb:135,embed:[1,3,4,12,39,55,57,58,59,101,128,173,190,234,235,241,242,256,262,282,289,290],emit:[55,61],emploi:21,empti:[50,89,99,140,167,179,225,229,245,253,267],emptiv:9,emul:[264,268,280],enabl:[1,8,9,24,30,31,32,34,35,37,38,39,40,41,42,43,44,45,46,47,48,49,50,51,52,53,54,55,57,58,59,62,73,76,77,78,87,93,129,130,131,132,134,135,151,181,186,190,194,205,207,208,209,211,212,213,219,224,225,235,238,239,241,242,246,249,252,257,266,273,274,275,276,280,284,287,289,290,292],enc:[198,200,201,203],enc_chang:252,encapsul:21,encod:[7,51,130,132,133,200,201,202,203,212,214,218,264,267,277,281,282],encoding_cborattr:222,encoding_tinycbor:222,encompass:[14,20],encount:[7,10,20,57,89,150,179,243],encourag:134,encrypt:[20,22,27,30,173,250,252],encrypt_connect:20,end:[9,20,28,30,55,89,128,140,158,168,170,179,187,204,225,233,245,246,264,275],endian:[23,61,89,128,190,264],endif:[219,223,225,232,233,258,267,275,276,282],energi:[9,21,22,89,257,292],english:128,enjoi:276,enough:[55,89,96,128,156,195,198,275],enqueu:[89,192],ensur:[11,12,21,59,89,93,97,100,101,156,181,187,222,223,224,225,236,238,239,243,247,251,257,268,269,270,278,281,284,287],entail:222,enter:[12,22,47,93,214,220,221,223,243,256,258,260,278,282],entir:[2,89,90,93,128,173,174,179,243,253,275],entireti:171,entiti:[43,248],entri:[20,22,72,129,140,141,142,145,148,150,154,155,156,161,164,171,173,174,179,204,208,214,219,222,253,279],enumer:[128,183,191,206],environ:[3,4,9,12,55,58,59,61,82,96,101,134,190,233,247,286],eof:[57,80],ephemer:254,epoch:100,equal:[29,72,89,179,205,224,225,226],equat:29,equival:[46,61,135,160,181,276,292],eras:[10,71,128,135,136,140,149,173,174,177,179,184,256,260,261,262,264,276],erase_sector:262,err:[97,159,204,208,217,218,223,274,276],error:[1,2,4,6,7,20,21,26,34,35,37,38,39,40,41,42,43,44,45,46,47,48,49,50,51,52,53,54,57,58,59,62,80,82,86,89,91,92,93,97,98,135,136,153,154,155,156,157,159,160,161,163,164,166,167,168,169,170,171,172,173,176,177,178,182,186,187,190,192,193,208,222,225,249,251,252,253,256,259,260,262,263,264,267,268,270,274,275,276,277,280,282,288],error_rsp_rx:[76,236],error_rsp_tx:[76,236],error_stat:223,escap:[241,268,282,289],especi:100,essenti:[43,61,225,243],establish:[20,27,78,236,238,249,250,252,259,261,264,276],estim:89,etc:[1,21,24,26,36,43,57,80,89,90,92,95,96,128,132,134,181,182,193,197,243,245,252,275,276],ethernet:[134,181],etyp:276,eui:264,eul:278,euler:278,ev_arg:[84,87,97,130],ev_cb:[84,87,89,130,238],ev_queu:87,eval:[261,276],evalu:[12,86,100,224,225,261,264,269,276],evalut:100,even:[4,10,86,89,96,128,151,179,193,199,211,222,274,276,280],event:[20,24,25,27,84,89,92,97,99,130,134,205,211,214,216,223,225,236,243,247,249,250,254,255,274,275,276,280,282,292],event_q:276,event_queu:130,eventq:[89,274,275],eventq_exampl:238,eventu:[4,99,100,179],ever:[89,90,128,140],everi:[1,32,61,97,98,99,134,150,179,190,252,254,256,258,270,275,282],everyon:[10,243],everyth:[1,93,97,222,243,267,268,275],evq:[84,87,89,216],evq_own:87,evq_task:87,exact:[96,128,186,192,223],exactli:[89,93,98,157,170,225],examin:[192,249,251,286],exampl:[1,2,3,6,7,9,12,22,23,24,25,30,31,55,57,58,59,60,61,62,64,80,82,83,89,90,91,93,94,96,97,98,99,100,101,128,130,133,152,173,174,180,183,186,187,188,205,207,208,209,210,214,219,222,223,234,235,236,241,242,243,245,247,248,252,256,258,260,264,267,268,269,270,271,275,277,278,279,280,281,282,285,286,288,289,290,292],example1:89,example2:89,exce:[179,215,219,241,289],exceed:20,except:[7,51,87,128,223,249,254,255,275,276],excerpt:[130,206,207,208,219,224,225,251,253,280],exchang:[14,21,22,27,28],excit:[7,235,246],exclud:[51,128,222,278],exclus:[22,91,98,206],exe:[12,59,60,82,83],exec_write_req_rx:[76,236],exec_write_req_tx:[76,236],exec_write_rsp_rx:[76,236],exec_write_rsp_tx:[76,236],execut:[1,2,7,11,12,30,34,35,37,38,39,40,41,42,43,44,45,46,47,48,49,50,51,52,53,54,55,57,58,59,61,62,67,80,82,85,87,90,92,93,96,99,101,133,136,137,139,190,195,216,225,229,231,232,236,243,249,251,252,253,254,255,258,267,275],exhaust:[20,97,140,179],exisit:27,exist:[2,10,20,24,29,41,46,49,50,71,94,140,146,151,157,159,160,161,166,167,169,170,172,173,176,177,179,186,206,208,213,225,228,240,241,242,250,256,259,260,261,262,263,268,270,275,276,277,279,280,281,282,284,285,287,288,289,290,292],exit:[8,80,241,259,261,264,275,276,289],expect:[6,20,43,61,84,92,93,97,129,130,134,222,226,227,228,229,230,243,247,254,255,264,267],experi:[22,265,278],experiment:99,expertis:269,expir:[84,86,87,192,194,238],expire_msec:194,expire_sec:194,expiri:[84,192],explain:[4,12,98,236,245,246,247,254,255,257,268,270,284,287,292],explan:[34,35,37,38,39,43,44,45,46,47,48,50,51,53,54,65,66,67,68,69,70,71,72,73,74,75,76,77,152,249],explanatori:[30,94,254,255],explic:278,explicit:267,explicitli:249,explor:[128,222,251,284],expos:[1,14,21,92,133,173,174,175,209,214,225,248,253],express:[23,168,225,226,253,275,276],ext:[12,260],ext_bynam:211,ext_bytyp:211,extend:[20,29,30,89,90,276,279,281],extended_dur:27,extended_period:27,extens:[21,30,137,264],extent:[241,242,256,282,289,290],extern:[12,29,40,93,97,134,135,175,181,186,205,223,231,241,242,269,270,276,289,290],extra:[38,42,47,89,134,152,190,239,241,244,249,282,289],extra_gdb_cmd:61,extract:[4,11,58,59,60,82,83,190,235,259],extrajtagcmd:[38,42,47],extrem:9,eyes:226,f401re:53,f411a55d7a5f54eb8880d380bf47521d8c41ed77fd0a7bd5373b0ae87ddabd42:285,f4discoveri:260,f_activ:140,f_active_id:140,f_align:140,f_close:[162,180],f_closedir:[162,180],f_dirent_is_dir:[162,180],f_dirent_nam:[162,180],f_filelen:[162,180],f_getpo:[162,180],f_magic:140,f_mkdir:[162,180],f_mtx:140,f_name:[162,180],f_oldest:140,f_open:[162,180],f_opendir:[162,180],f_read:[162,180],f_readdir:[162,180],f_renam:[162,180],f_scratch:140,f_scratch_cnt:140,f_sector:140,f_sector_cnt:140,f_seek:[162,180],f_unlink:[162,180],f_version:140,f_write:[162,180],face:222,facil:[19,101,231,238],fact:[135,269],factor:9,factori:263,fail:[20,42,57,80,89,97,140,143,160,161,173,179,226,227,228,230,241,246,252,259,260,263,264,267,269,276,289],fail_msg:226,failov:222,failur:[20,84,89,97,99,100,128,136,141,142,143,145,146,148,149,150,152,153,154,156,157,159,160,163,166,167,168,169,170,171,172,176,177,178,182,186,187,190,192,193,194,215,217,218,219,226,232,233,251,252,253,267],fair:89,fairli:[24,55,61,89,98],fall:[96,101,186,292],fallback:27,fals:[90,222,224,226],famili:[4,101,135,151,247],familiar:[3,12,225,235,236,241,245,246,248,275,276,282,289,292],fanci:99,faq:[11,13],far:[246,282],fashion:[92,140,179,235],fast:275,fat2n:[7,61],fatf:[7,136,151,152],fault:130,favorit:[235,240],fcb:[7,129,141,142,143,144,145,146,147,148,149,150,205],fcb_append:[140,142,143],fcb_append_finish:[140,141],fcb_append_to_scratch:141,fcb_entri:[140,141,142,145,150],fcb_err_nospac:141,fcb_err_novar:145,fcb_getnext:140,fcb_init:140,fcb_log:205,fcb_rotat:[140,141],fcb_walk:140,fcb_walk_cb:150,fda_id:179,fe80:[241,289],fe_area:[140,145,150],fe_data_:140,fe_data_len:[140,145,150],fe_data_off:[140,145,150],fe_elem_:140,fe_elem_off:140,feat:276,featur:[1,3,11,19,20,30,90,96,99,140,152,173,214,222,225,234,249,264,278,284],feedback:[235,240,257,276],feel:3,femal:288,fetch:[1,12,40,57,80,236,238,239,247,257,269,270,275,284,287],few:[1,6,14,25,31,55,61,90,93,94,223,246,251,254,264,267,276,292],ffconf:151,ffffffff:262,ffs2nativ:[7,61],fhss:21,ficr:23,fictiti:[269,270],fie_child_list:179,field:[20,27,84,85,89,93,128,130,175,187,200,202,206,207,208,214,219,222,223,225,249,251,253,254,255,269,270,278,280],fifo:140,figur:[89,128,129,140],file:[1,2,4,6,7,10,11,12,34,36,37,41,43,46,48,50,55,57,58,59,60,61,64,70,71,80,81,82,83,94,95,96,101,128,129,130,134,173,183,186,188,195,205,206,207,210,211,214,222,224,225,229,231,235,236,238,240,242,244,246,247,253,256,258,259,260,262,263,264,265,267,268,269,271,275,276,278,286,290],file_nam:61,filenam:[1,34,35,37,38,39,40,41,42,43,44,45,46,47,48,49,50,51,52,53,54,57,58,59,62,70,71,93,151,156,160,162,166,169,173,179,222,247,275],filesystem:[55,129,151,195],fill:[10,48,95,99,140,141,143,145,146,182,198,199,246,251,254,255,267,275,276],filter:[2,22,27,30,72,256],find:[1,2,3,20,28,34,55,61,88,89,94,96,129,146,181,211,223,224,228,234,235,241,242,246,247,256,259,260,263,268,282,285,288,289,290,292],find_info_req_rx:[76,236],find_info_req_tx:[76,236],find_info_rsp_rx:[76,236],find_info_rsp_tx:[76,236],find_type_value_req_rx:[76,236],find_type_value_req_tx:76,find_type_value_rsp_rx:76,find_type_value_rsp_tx:76,fine:[9,254,255],finish:[4,98,99,141,179,193,264,275],fip:21,fire:[84,192,194,243,250,282],firmwar:[128,152,236,241,242,259,261,264,268,275,276,289,290],first:[2,3,6,8,12,21,22,29,33,57,58,59,60,63,82,83,84,87,89,90,91,93,99,100,101,128,129,140,168,173,174,179,180,183,190,197,199,211,214,222,225,235,236,243,245,248,249,250,251,253,254,255,257,258,264,268,274,275,276,278,282,284,287,292],fit:[4,89,100,171,179,249,250,265],five:[20,21,22,157,170,236],fix:[6,10,11,90,100,128,271],fl_area:141,fl_data_off:141,flag:[1,6,12,27,29,55,57,58,59,61,62,64,80,81,82,89,94,99,128,160,222,239,247,251,253,274,275,278,285,288],flash0:152,flash:[1,9,39,43,48,55,57,58,59,61,95,96,129,134,141,142,146,152,174,176,177,180,181,185,186,188,195,205,222,225,236,256,260,261,262,264,265,276],flash_area:[140,150],flash_area_bootload:[93,128,176,177,224,225],flash_area_image_0:[93,128,176,177],flash_area_image_1:[93,128,176,177,225],flash_area_image_scratch:[93,128,176,177,224],flash_area_nff:[176,177,224,225],flash_area_noexist:224,flash_area_read:[140,145,150],flash_area_reboot_log:[224,225],flash_area_to_nffs_desc:[176,177],flash_area_writ:[140,141],flash_area_x:140,flash_id:[135,182,184],flash_map:[7,129,176,177,182,224,225],flash_map_init:225,flash_own:[224,225],flash_spi_chip_select:186,flash_test:[7,130],flat:[89,199,205],flavor:256,flexibl:[89,96,234,249,269,270],flg:275,flight:89,float_us:277,flood:31,flow:[21,130,193,247,254,255],flow_ctl:193,fly:190,fmt:130,focu:243,folder:[4,10,12,33,55,59,63,240,259],follow:[1,2,3,4,6,7,8,10,11,12,19,20,21,23,24,26,27,29,30,31,32,37,38,43,50,51,55,57,58,59,60,61,64,66,67,71,72,73,77,78,80,81,82,83,89,91,93,94,96,98,99,100,101,128,130,131,133,134,135,136,140,152,160,167,168,169,173,174,175,179,180,181,187,189,190,200,202,205,206,207,208,209,211,212,222,223,224,225,226,227,228,229,230,231,235,236,238,239,240,243,246,247,248,249,251,253,254,255,256,257,258,259,260,261,262,263,264,267,268,269,270,271,274,275,276,277,278,279,280,281,282,284,285,287,288],foo:129,foo_callout:129,foo_conf_export:129,foo_conf_set:129,foo_val:129,footer:[128,258],footprint:[9,132,134],fop:165,fopen:160,forc:[41,49,52,89,222],forev:[87,91,98,99,160,161,233],forgeri:22,forget:[80,160,161,235,274,275,276],forgot:275,fork:10,form:[1,19,22,23,26,66,89,99,179,225,251,252,254,264,267,269],formal:[7,20],format:[8,29,50,66,68,71,72,89,130,132,151,152,173,176,177,197,198,199,206,223,225,226,229,247,254,258,268,269,270,278,285,288],former:179,formula:[3,60,83],forth:[129,199],fortun:55,forver:27,forward:[100,249],found:[1,20,33,55,63,90,93,148,173,179,199,247,252,253,254,256,260,262,288],foundat:[4,21,31,132,241,242,256,262,269,275,276,282,289,290],four:[19,22,47,128,168,172],fraction:[100,267],frame:[214,217,218,243,264],framerwork:131,framework:[21,28,97,132,206,212,213,231,232,247,277,278,279,282,283,284],frdm:53,free:[2,4,73,88,89,90,140,179,215,219,222,241,242,250,252,256,262,282,286,289,290],freebsd:101,freed:[89,90,179],freedom:[252,254,255],freq_hz:192,frequenc:[21,24,86,93,97,100,134,181,189,192,194,223,243,264],frequent:[10,19,21,22,97,254,255,282],freshli:89,friend:31,friendli:134,from:[1,4,6,7,8,9,10,11,12,19,20,22,23,26,27,30,31,32,35,36,38,39,41,43,44,45,46,47,49,50,51,55,56,60,61,62,64,65,66,68,69,70,71,72,73,76,77,79,83,84,85,86,87,88,89,90,92,93,94,95,96,99,100,101,128,129,131,132,133,135,136,137,139,140,146,152,153,154,155,156,160,161,162,163,164,166,168,169,171,176,177,179,180,182,186,187,190,192,193,195,198,199,205,206,207,208,209,210,211,212,213,214,216,217,222,223,224,225,226,227,228,230,231,233,235,236,238,239,241,242,243,245,246,247,248,251,252,253,254,255,256,257,258,259,260,261,262,263,264,267,268,269,270,275,276,278,282,284,285,286,288,289,290],front:[89,179],fs_access_append:160,fs_access_read:[153,160,163,168],fs_access_trunc:[157,160,166,169,170],fs_access_writ:[157,160,166,169,170],fs_cli:7,fs_cli_init:215,fs_close:[157,160,163,166,168,169,170,171,172],fs_closedir:[136,161],fs_dir:[152,154,155,156,161,162,164],fs_dirent:[7,152,154,155,156,161,162,164],fs_dirent_is_dir:[154,156,161,164],fs_dirent_nam:[136,154,155,161,164],fs_eaccess:167,fs_ealreadi:172,fs_ecorrupt:[167,176,177],fs_eempti:167,fs_eexist:[165,167],fs_eful:167,fs_ehw:167,fs_einval:167,fs_enoent:[136,154,155,156,161,164,166,167],fs_enomem:167,fs_eo:167,fs_eoffset:167,fs_eok:167,fs_eunexp:167,fs_euninit:167,fs_fcb:222,fs_file:[7,152,153,157,158,160,162,163,166,168,169,170],fs_filelen:170,fs_if:[162,180],fs_ls_cmd:215,fs_ls_struct:215,fs_mkdir:[7,172],fs_mount:7,fs_name:152,fs_nmgr:7,fs_op:[165,180],fs_open:[153,157,163,166,168,169,170,171,172],fs_opendir:[136,154,155,156,164],fs_read:[153,160,168,171],fs_readdir:[136,154,155,156,161],fs_regist:180,fs_unlink:159,fs_write:[157,166,172],fssl:[11,58],fsutil:[7,152],fsutil_r:152,fsutil_w:152,ftdichip:247,fulfil:251,full:[1,7,8,20,21,28,30,48,55,93,128,129,135,141,156,160,166,167,179,182,195,205,214,222,224,225,236,240,246,249,252,253,258,275,276,278,282,292],fuller:179,fulli:[9,21,128,173,174,179,222,246,255,269,270,276],fun:[235,275],func:[89,97,99,129,187,192,194],fundament:[1,292],funtion:199,further:[6,93,97,187],furthermor:[92,128,173,174,179,222,243,254,255],fuse:55,futur:[84,89,179,187,206,214,225,264,269,270,271],g_bno055_sensor_driv:208,g_bno055stat:208,g_led_pin:[240,243,258],g_mbuf_buff:89,g_mbuf_mempool:89,g_mbuf_pool:89,g_mystat:223,g_nmgr_shell_transport:217,g_os_run_list:85,g_os_sleep_list:85,g_stats_map_my_stat_sect:223,g_task1_loop:258,gain:[91,98,180,246,276],gap:[18,19,20,21,30,179,248,251,253,275,276,277],garbag:140,gatewai:264,gatt:[14,18,21,27,30,31,32,248,251,253,275,276,277],gatt_acc:251,gatt_adc_v:276,gatt_co2_v:274,gatt_co2_val_len:274,gatt_srv:276,gatt_srv_sns_access:276,gatt_svr:[253,274,276,278],gatt_svr_chr_access_gap:[251,253],gatt_svr_chr_access_sec_test:[253,274],gatt_svr_chr_sec_test_rand_uuid:[253,274],gatt_svr_chr_sec_test_static_uuid:[253,274],gatt_svr_chr_writ:[274,276],gatt_svr_register_cb:253,gatt_svr_sns_access:[274,276],gatt_svr_svc:[251,253,274],gatt_svr_svc_adc_uuid:276,gatt_svr_svc_co2_uuid:274,gatt_svr_svc_sec_test_uuid:[253,274],gaussian:21,gavin:58,gc_on_oom_test:267,gc_test:267,gcc:[4,7,57,101],gcc_startup_:93,gcc_startup_myboard:93,gcc_startup_myboard_split:93,gcc_startup_nrf52:[93,259,261,282],gcc_startup_nrf52_split:[259,261,263,264,282],gdb:[4,7,12,38,47,61,62,93,241,242,243,246,256,258,259,260,262,263,276,282,289,290],gdb_arduino_blinki:12,gdbmacro:7,gdbpath:12,gdbserver:6,gear:101,gen:[27,30],gen_task:238,gen_task_ev:238,gen_task_prio:238,gen_task_stack:238,gen_task_stack_sz:238,gen_task_str:238,gener:[1,11,15,16,17,18,19,20,21,23,27,28,29,31,34,35,43,55,61,62,87,89,90,91,93,99,128,136,173,174,186,199,222,224,227,228,230,235,236,239,240,241,242,243,244,246,247,249,250,253,254,255,256,257,258,259,260,261,262,263,264,267,268,269,274,275,278,282,285,288,289,290],get:[2,4,6,7,8,9,10,11,23,55,56,58,59,60,61,64,76,79,81,82,83,85,87,89,90,91,92,93,95,96,97,98,99,100,128,129,133,134,140,150,157,160,163,166,171,179,182,186,190,192,199,206,210,212,222,225,226,235,238,240,243,245,247,249,251,253,254,255,256,257,259,260,262,263,264,267,268,274,275,276,281,282,288,292],gettng:265,gfsk:21,ggdb:6,ghz:[21,268],gist:[134,186],gister_li:210,git:[11,55,58,80,81,82,101,256,268,269,270,271],github:[1,7,10,11,33,55,57,58,59,63,80,81,82,101,183,235,256,268,269,270,271,275,276,284],githublogin:271,githubpassword:271,githubusercont:[11,57,58,59,80,81,82],give:[55,186,222,235,243,246,254,255,264,269,270,276],given:[12,20,42,84,86,87,89,90,96,99,100,128,136,139,145,146,152,182,186,190,192,193,199,206,210,211,243,270],glanc:249,glibc:57,global:[1,29,62,89,90,91,175,205,206,208,223,231,251,275],gmt:100,gnd:[8,264,276,278,288],gnu:[3,4,12,38,47,241,242,256,260,262,263,282,289,290],goal:[55,101,287],gobjcopi:6,gobjdump:6,gobl:81,goe:[61,231,267,275],going:[96,222,254,258,275,276],golang:[11,59,82],gone:250,good:[7,9,22,55,91,93,97,128,151,222,246,249,255,264,275],googl:[254,284],gopath:[11,57,58,59,60,80,81,82,83],got:[274,275,276],govern:[275,276],gpg:[57,80],gpio:[8,96,134,188,190,193,238],gpio_ev:238,gpio_l:238,gpl:[4,241,242,256,260,262,263,282,289,290],gplv3:[241,242,256,262,282,289,290],gpo:181,grab:88,gracefulli:233,graduat:276,grain:9,grant:91,granular:100,graph:[1,50,62,276],graviti:278,great:[8,21,128,224,240,275,276],greater:[21,29,89,179,224],greatest:[128,179],green:[2,10,12,256,260,261,268,278,285],grid:55,ground:[276,278],group:[2,10,20,76,131,134,214,223,225,236,264],grow:[53,243],guarante:[89,90],guard:92,guid:[7,11,12,18,59,62,64,82,208,209,225,236,238,243,248,253,255,265,267,269,285,288],guinea:244,gyro:278,gyro_rev:278,gyroscop:[206,278],h_mynewt_syscfg_:225,hack:[7,9,12,235,240,276],had:[89,92,128,222],hal:[1,7,9,48,55,61,86,95,134,135,176,177,180,181,187,190,192,193,208,238,246,256,260,262,276,278,282,292],hal_bsp:[7,93,134,185,207,256,259,260,262,275,280],hal_bsp_core_dump:182,hal_bsp_flash_dev:[93,135,182,185],hal_bsp_get_nvic_prior:182,hal_bsp_hw_id:182,hal_bsp_init:[182,207],hal_bsp_max_id_len:182,hal_bsp_mem_dump:182,hal_bsp_power_deep_sleep:182,hal_bsp_power_off:182,hal_bsp_power_on:182,hal_bsp_power_perus:182,hal_bsp_power_sleep:182,hal_bsp_power_st:182,hal_bsp_power_wfi:182,hal_common:[7,246,260,262],hal_debugger_connect:191,hal_flash:[7,93,135,152,182,185,256,260,262],hal_flash_align:184,hal_flash_eras:184,hal_flash_erase_sector:184,hal_flash_init:184,hal_flash_ioctl:184,hal_flash_read:184,hal_flash_writ:184,hal_gpio:[7,136,183,186,238],hal_gpio_init_in:186,hal_gpio_init_out:[99,186,238,240,243,258],hal_gpio_irq_dis:186,hal_gpio_irq_en:[186,238],hal_gpio_irq_handler_t:186,hal_gpio_irq_init:[186,238],hal_gpio_irq_releas:186,hal_gpio_irq_trig_t:186,hal_gpio_irq_trigg:186,hal_gpio_mode_:186,hal_gpio_mode_in:186,hal_gpio_mode_nc:186,hal_gpio_mode_out:186,hal_gpio_mode_t:186,hal_gpio_pul:186,hal_gpio_pull_down:186,hal_gpio_pull_non:186,hal_gpio_pull_t:186,hal_gpio_pull_up:[186,238],hal_gpio_read:186,hal_gpio_toggl:[99,186,238,240,258],hal_gpio_trig_both:186,hal_gpio_trig_fal:186,hal_gpio_trig_high:186,hal_gpio_trig_low:186,hal_gpio_trig_non:186,hal_gpio_trig_ris:[186,238],hal_gpio_writ:[183,186,243],hal_i2c_begin:187,hal_i2c_end:187,hal_i2c_init:187,hal_i2c_master_data:187,hal_i2c_master_prob:187,hal_i2c_master_read:187,hal_i2c_master_writ:187,hal_i2c_prob:187,hal_i2c_read:187,hal_i2c_writ:187,hal_os_tick:[189,259,282],hal_reset_brownout:191,hal_reset_caus:[191,280],hal_reset_pin:191,hal_reset_por:191,hal_reset_reason:191,hal_reset_request:191,hal_reset_soft:191,hal_reset_watchdog:191,hal_rtc:151,hal_spi:[136,190],hal_spi_abort:190,hal_spi_config:190,hal_spi_data_mode_breakout:190,hal_spi_dis:190,hal_spi_en:190,hal_spi_init:[136,190],hal_spi_lsb_first:190,hal_spi_mod:190,hal_spi_mode0:190,hal_spi_mode1:190,hal_spi_mode2:190,hal_spi_mode3:190,hal_spi_moden:190,hal_spi_msb_first:190,hal_spi_set:[135,190],hal_spi_set_txrx_cb:190,hal_spi_slave_set_def_tx_v:190,hal_spi_tx_v:190,hal_spi_txrx:190,hal_spi_txrx_cb:190,hal_spi_txrx_noblock:190,hal_spi_type_mast:190,hal_spi_type_slav:190,hal_spi_word_size_8bit:190,hal_spi_word_size_9bit:190,hal_system:191,hal_system_clock_start:191,hal_system_reset:191,hal_system_restart:191,hal_system_start:191,hal_tim:[86,192],hal_timer_cb:[86,192],hal_timer_config:192,hal_timer_deinit:192,hal_timer_delai:192,hal_timer_get_resolut:192,hal_timer_init:192,hal_timer_read:192,hal_timer_set_cb:192,hal_timer_start:192,hal_timer_start_at:192,hal_timer_stop:192,hal_uart:275,hal_uart_blocking_tx:193,hal_uart_clos:193,hal_uart_config:[193,275],hal_uart_flow_ctl:193,hal_uart_flow_ctl_non:[193,275],hal_uart_flow_ctl_rts_ct:193,hal_uart_init:193,hal_uart_init_cb:[193,275],hal_uart_par:193,hal_uart_parity_even:193,hal_uart_parity_non:[193,275],hal_uart_parity_odd:193,hal_uart_rx_char:193,hal_uart_start_rx:193,hal_uart_start_tx:[193,275],hal_uart_tx_char:193,hal_uart_tx_don:193,hal_watchdog_en:194,hal_watchdog_init:194,hal_watchdog_tickl:194,hal_xxxx:181,half:[16,17,93,100],halfwai:128,halgpio:186,halsystem:191,halt:[92,189,190,256,260,262],haluart:193,hand:[222,235,243,267],handbook:[259,263],handi:[93,276],handl:[17,20,27,28,30,61,89,101,134,135,136,152,153,154,155,156,160,161,164,169,170,171,172,179,205,209,210,214,236,238,250,251,252,274,275,276,282],handler:[87,92,93,131,186,210,212,215,217,219,220,238,243,274,275,276,277],happen:[9,20,26,129,140,179,250,253,254,255,256,268,270],happi:[7,9],har:288,hard:[97,130],hardcod:[25,27],hardwar:[2,3,5,6,7,9,20,21,24,25,31,34,86,93,95,96,128,134,173,174,179,182,183,184,185,186,187,189,191,192,193,194,208,222,225,238,243,246,247,254,255,256,258,259,260,261,265,268,269,275,282,292],harm:128,has:[2,3,4,7,10,11,12,20,22,24,26,30,34,36,43,50,55,57,58,59,61,62,77,80,81,82,84,85,86,87,88,89,90,92,93,96,97,98,99,128,129,130,132,134,138,140,152,153,165,169,173,179,186,187,190,192,193,195,208,210,222,223,225,231,233,236,239,241,242,243,244,251,252,253,256,258,259,260,264,267,268,269,270,274,275,281,282,289,290,292],hash:[34,37,43,46,71,128,179,222,239,285,288],have:[1,2,3,6,7,8,9,11,12,19,20,22,24,30,32,43,50,52,54,55,57,58,59,60,61,62,64,80,81,82,83,84,87,89,90,92,93,95,96,97,98,99,101,128,130,132,134,135,137,140,143,173,174,179,181,185,186,192,193,214,220,222,223,224,225,234,235,236,238,239,240,241,242,244,245,246,247,250,251,253,254,255,256,257,258,259,260,261,262,263,264,267,268,269,270,272,274,275,276,277,278,279,280,281,282,284,285,286,287,288,289,290,292],haven:[3,136,234,270,275,276,292],hci1:247,hci:[21,245],hci_adv_param:249,hci_common:236,hdr:[128,226],hdr_ver:197,head:[11,58,80,81,82,87,89,210,244],header:[1,37,39,46,55,57,58,59,61,93,128,132,140,141,179,183,186,205,207,225,231,236,258,275,276],heading1:244,heading2:244,heading5:244,headless:2,health:254,heap:[90,92,93],heart:243,held:269,hello:[12,69,157,170,193,236,257,268,285,286,288,292],help:[1,8,12,31,34,35,37,38,40,41,42,43,44,45,46,47,48,49,50,51,52,53,54,57,58,59,62,64,65,67,68,69,70,71,72,73,74,75,76,77,80,81,82,92,94,95,100,134,199,219,222,224,241,242,243,244,245,246,249,256,258,259,261,264,265,267,268,271,275,276,278,282,289,290],helper:[1,61,89,94,135,254,255],henc:[128,234],her:92,here:[1,3,8,10,11,29,32,55,73,76,77,84,87,89,90,93,94,97,99,129,130,140,156,157,160,163,171,173,186,190,199,205,206,208,214,222,223,224,225,232,234,235,238,244,247,251,253,254,255,256,258,259,260,263,264,267,268,269,270,275,276,286,292],hertz:86,hex:[7,37,43,48,71,187,222,262,264,274,282],hexidecim:66,hfxo:24,hidapi:4,hidraw:4,hierarchi:[152,225,231],high:[9,18,21,64,86,98,134,186,238,241,243,289],high_duti:27,higher:[11,14,20,21,55,58,59,72,80,81,82,91,92,98,99,181,205,211,224,225,234,243,247,267,270],highest:[85,91,92,99,224,225,243],highli:234,highlight:[2,6,30,101,235,256,259,261,263,268,276,277,282],hint:55,his:92,histori:224,hit:[36,258],hl_line:[207,208],hog:243,hold:[33,43,63,89,90,156,187,198,208,214,235,243,264,269,276],hole:[179,276],home:[7,11,59,93,222,246,258,267,271,275],homebrew:[4,6,7,11,36,56,60,79,83],homepag:[1,43,61,130,267,275,276],hook:[97,262,275,288],hop:[21,134],host:[7,9,21,22,23,26,29,30,66,70,71,84,87,89,128,212,241,242,244,246,247,251,252,253,256,267,268,275,276,277,281,282,289,290],hotkei:[241,289],hour:100,how:[2,3,4,5,6,7,8,11,12,20,21,23,30,55,57,58,59,60,66,80,81,82,83,89,91,93,96,100,128,129,130,140,146,148,166,173,187,190,200,205,207,208,219,222,223,226,229,231,234,235,236,239,240,243,244,245,246,247,250,251,252,254,255,256,257,258,259,260,261,262,263,264,266,267,268,274,275,276,278,279,281,282,284,285,286,287,288,292],how_to_edit_doc:244,howev:[3,57,80,89,96,99,101,128,130,173,179,186,223,239,259,269],htm:247,html:[4,33,63,152,241,242,256,260,262,282,289,290],http:[1,4,10,11,12,33,39,55,57,58,59,61,63,80,81,82,101,130,137,183,235,241,242,247,254,256,259,260,262,263,267,269,271,275,276,282,288,289,290],httperror404:[57,80],hub:268,human:[247,269],hw_bsp_nativ:61,hw_drivers_nimble_nrf51:222,hw_hal:55,hw_mcu_nordic_nrf51xxx:222,hypothet:20,i2c:[8,134,135,181,278,279,282],i2c_0:[277,278,279,282],i2c_0_itf_bno:207,i2c_0_itf_li:207,i2c_num:187,i2s:256,i2s_callback:256,i386:[4,6],iOS:[250,274,276,277,279,281,284],ibeacon:[23,246,257,292],icon:[10,12],id16:253,id3:[33,63],id_init:225,idcod:256,idea:[61,89,91,97,249],ideal:21,ident:[18,20,22,23,27,30,66,89,101,133,222,223,231],identifi:[1,8,19,20,27,29,34,71,93,99,128,129,179,182,187,254,255,259,261,264,268,276,285,288],idl:[27,77,97,243,246,275,285,288],idx:[27,135,179],ietf:199,if_rw:133,ifdef:[222,225,232,258,282],ifndef:[225,275,276],ignor:[6,27,82,90,152,166,173,225,241,289],ih_flag:128,ih_hdr_siz:128,ih_img_s:128,ih_key_id:128,ih_mag:128,ih_tlv_siz:128,ih_ver:128,iii:128,illustr:[12,89,91,92,128,243,276,282],imag:[2,6,7,12,31,34,38,39,42,43,47,55,57,58,59,61,64,78,80,81,82,93,94,96,101,130,131,196,197,198,200,201,203,223,224,234,241,242,246,250,256,257,258,265,274,275,286,287,289,290,292],image_ec256:[256,259,260,261,262,263,264,268,278,285,286,288],image_ec:[7,256,259,260,261,262,263,264,268,278,285,286,288],image_f_ecdsa224_sha256:128,image_f_non_boot:128,image_f_p:128,image_f_pkcs15_rsa2048_sha256:128,image_f_sha256:128,image_head:128,image_header_s:128,image_mag:128,image_magic_non:128,image_ok:128,image_rsa:[7,256,259,260,261,262,263,264,268,278,285,286,288],image_tlv:128,image_tlv_:128,image_tlv_ecdsa224:128,image_tlv_rsa2048:128,image_tlv_sha256:128,image_valid:[7,256,260,261,263,268,278,285,286,288],image_vers:[128,197,198],img:[37,46,71,235,236,239,240,241,242,246,247,250,256,259,260,261,262,263,264,268,275,278,282,285,288,289,290],img_data:204,img_start:191,imgmgr:[7,130,131,152,195,225,236,276],imgmgr_max_ver_str:198,imgmgr_module_init:225,imgr_list:[200,201,203],imgr_upload:204,imgr_ver_jsonstr:198,immedi:[26,87,93,128,169,179,190,192,244,249,254,255],impact:[24,179],impl:61,implemen:66,implement:[9,10,21,32,61,66,87,89,90,93,95,96,128,129,130,131,151,152,173,179,181,183,185,186,187,188,189,190,191,195,199,206,207,209,211,213,214,220,225,231,238,248,251,253,254,264,267,276,277,278,282],impli:[254,255,267,270,275,276],implicit:267,impos:[128,173,174,179],imposs:[19,175],impract:253,impress:276,improv:258,imuplu:278,inc:[4,241,242,256,262,282,289,290],includ:[1,4,7,9,10,14,15,16,17,19,20,21,22,26,27,28,31,43,50,59,61,84,87,89,90,91,93,95,96,97,98,99,100,128,130,133,134,135,136,138,151,152,153,154,155,156,157,158,159,160,161,162,163,164,165,166,167,168,169,170,171,172,173,174,175,176,177,178,179,180,181,182,183,187,190,192,193,195,205,206,207,210,211,212,214,222,224,225,231,235,236,238,239,241,243,247,248,249,251,254,255,259,267,269,270,275,276,277,278,280,281,282,287,289],include_tx_pow:27,incom:[20,87,193,195,214,215,217,238],incompat:[57,80,269],incomplet:[29,93,159],incomplete_block_test:267,incorrect:[42,100],incr:182,increas:[21,22,89,179,214,215,219,225,241,243,289],increasin:140,increment:[89,100,129,179,223],incub:[7,55,183,225,235,276],inde:[92,262],indefini:[254,255],indent:6,independ:[22,96,128,134,181,182,184,186,187,189,191,192,193,194,225,275],indetermin:267,index:[31,72,128,247],indian:100,indic:[7,10,19,20,26,28,29,30,87,90,93,97,128,130,132,152,158,160,167,179,186,187,192,204,211,214,219,222,224,225,239,251,253,256,259,260,263,267,268,282,284],indirect:276,individu:[11,99,128,129,134,186,225,230,236,269],industri:[21,151],ineffici:179,infinit:[87,90,92,225,243,258],info:[39,57,58,59,61,64,65,66,67,68,69,70,71,72,73,74,75,76,77,80,81,82,90,99,140,141,145,219,239,252,256,260,262,263,268,274,276],inform:[1,6,7,12,20,22,23,27,29,34,37,39,40,57,58,59,61,62,64,66,71,80,81,82,87,89,90,93,95,96,99,100,128,132,133,145,179,205,206,208,209,219,222,223,225,234,235,238,239,242,243,246,249,252,253,254,255,256,258,264,269,270,271,275,276,278,282,285,288,290],infrastructur:246,ing:[134,254,255],inher:[1,23,251],inherit:[1,4,59,91,175,206],ininclud:223,init:[50,55,207,211,225,275,276],init_app_task:92,init_func_nam:225,init_funct:225,init_stag:225,init_task:[238,243],init_tim:[258,282],initi:[16,19,21,23,25,26,27,28,61,84,86,87,89,90,91,92,93,97,98,99,129,130,134,138,146,152,167,176,177,178,179,181,182,184,186,187,190,192,193,196,199,203,205,207,210,211,212,214,215,219,231,232,236,238,240,247,248,252,254,255,258,267,274,275,276,277,278,282],initialis:[208,256],inod:[173,175],inoper:[26,254,255],input:[20,22,27,100,134,181,186,190,238,241,262,267,289],inquiri:[20,29],insert:[99,179],insid:[24,89,92,161,182,258,262,267],insight:[134,243],inspect:[48,128,129,252],instal:[3,7,9,33,39,54,55,63,78,92,93,94,136,210,236,238,239,240,241,243,245,246,247,256,257,259,260,261,262,263,267,268,270,272,275,277,278,279,281,282,284,285,286,287,288,289,292],instanc:[2,3,9,27,62,89,175,176,177,179,205,223,249,254,255,256],instant:20,instantan:243,instanti:[92,134],instantli:98,instead:[7,11,12,24,87,90,98,128,130,222,225,236,238,250,256,258,259,260,261,262,263,267,271,274,275,276,277,280],instruct:[3,4,7,11,55,57,62,80,85,96,236,238,241,242,256,259,263,277,278,279,280,282,286,289,290],insuffici:[20,89,167],insur:[90,99],int16_t:100,int32_max:27,int32_t:[84,100,193,254,255],int64_t:100,int8:129,int_max:89,integ:[199,206,223,225],integr:[12,22,90,179,187,223],intellig:181,intend:[24,29,36,176,177,187,234],inter:[179,187,238],interact:[2,8,130,132,195,241,250,258,265,289],interchang:199,interconnect:[9,132],interdepend:[129,225],interest:[7,14,18,89,93,181,222,240,246,249,254,292],interfac:[4,18,21,30,31,89,99,128,133,134,135,136,151,152,181,182,184,186,187,189,190,191,193,194,205,208,209,235,245,247,248,256,260,262,275,278,279,282,288],intermedi:[159,160,166],intern:[7,20,89,92,93,97,134,135,140,167,176,177,178,185,192,194,195,199,215,219,256,276],internet:[7,12,21,236,238,239,247,257,268,284,287],interoper:[132,133],interpret:[137,139,206,210],interrog:276,interrupt:[86,87,93,128,182,186,189,190,192,193,276],interrupt_prior:276,interv:[20,27,29,97,99,206,210,211,238,278,282],interval_max:27,interval_min:27,intervent:96,intial:219,intiat:93,introduc:[1,30,179,224,225],introduct:[243,292],introductori:284,intuit:128,invalid:[20,86,128,136,142,152,153,167,171,172,179,190,192,251,267],invers:[91,98],invert:98,invoc:[6,253],invok:[2,267,271,282],involv:[16,17,19,22,93,96,181,187,267],io_cap:27,ioctl:152,iot:21,iotiv:277,ipsp:21,ipv6:21,irk:[19,27],irq:186,irq_num:182,irq_prio:[135,136],isbuildcommand:12,ism:21,ismylaptop:[275,276],isn:[93,179,246],isol:[93,222],isshellcommand:12,issu:[1,6,30,55,66,92,98,128,132,152,173,179,187,236,259,260,261,263,264,272,275,276],ist:100,it_len:128,it_typ:128,ital:244,ite_chr:251,item:[1,87,93,129,180,210,255],iter:[90,99,128,154,155,156,161,164,179,211],itf:208,its:[7,10,11,18,19,20,55,61,85,87,89,90,91,92,93,96,97,99,128,130,135,140,158,168,171,173,174,179,186,187,190,205,222,223,224,225,226,231,235,239,240,243,244,245,246,249,251,252,253,254,255,264,269,275,280,286,292],itself:[26,61,89,90,99,128,134,138,140,180,195,200,211,225,235,259,267,275,276],iv_build_num:128,iv_major:128,iv_minor:128,iv_revis:128,jan:100,javascript:55,jb_read_next:199,jb_read_prev:199,jb_readn:199,je_arg:199,je_encode_buf:199,je_wr_comma:199,je_writ:199,jira:10,jlink:[61,93,239,259,261,268,278,282,285],jlink_debug:61,jlink_dev:61,jlinkex:[259,261,264,276],jlinkgdbserv:[241,282,289],job:[1,34,35,37,38,39,40,41,42,43,44,45,46,47,48,49,50,51,52,53,54,57,58,59,62,85,92,93,214,251],join:[3,134,234,268,292],json:[7,12,34,37,51,55,61,201,202,203,204,235,236,240,267,275],json_array_t:199,json_attr_t:[199,204],json_buff:[199,204],json_buffer_read_next_byte_t:199,json_buffer_read_prev_byte_t:199,json_buffer_readn_t:199,json_decod:[204,267],json_encod:[198,199,200,201,202,203,267],json_encode_object_entri:[201,202,203],json_encode_object_finish:[200,203],json_encode_object_start:[200,201,202],json_enum_t:199,json_read:199,json_read_object:199,json_simple_decod:267,json_simple_encod:267,json_typ:199,json_valu:[199,200,201,202,203],json_value_int:[199,202],json_value_str:199,json_value_stringn:199,json_write_func_t:199,jtag:[4,38,42,47,256,259,260,262,268,282,288],jul:80,jump0:67,jump:[128,222],jumper:[8,235,262,275,276,288],just:[1,7,8,20,22,23,62,84,87,93,94,99,100,128,135,136,151,166,171,222,235,250,251,254,255,256,258,264,271,272,275,276],jv_len:199,jv_pad1:199,jv_type:199,jv_val:199,k30:[274,275],k64f:53,keep:[9,22,24,92,128,130,134,140,179,190,207,214,215,219,222,235,240,243,267,276],keg:[60,83],kei:[8,19,20,21,31,37,46,57,80,93,128,129,179,198,199,200,202,225,251,264,268,275,278],kept:[85,128,140],kernel:[1,7,9,51,55,61,93,130,134,181,211,222,225,238,246,247,275,276,277,278,280,282],kernel_o:222,keyboard:[12,22,130],keyboarddisplai:27,keyboardonli:27,keychain:[57,80],keystor:27,keyword:[1,61,94,130,267,269,275,276],khz:[190,256,260],kick:[97,254,255],kilobyt:96,kind:[31,134,241,275,276,289],kit:[8,47,61,235,239,240,241,242,257,259,276,289,290,292],klibc:101,know:[1,8,12,30,61,130,206,210,223,224,243,251,252,254,255,257,258,268,275,276,287,292],known:[21,55,100,160,161,179,243,249],l13:259,l2cap:21,lab:32,label:[8,93,262,276],lack:[140,151,222],lag:253,languag:[11,12,55,96,137,275,276],laptop:[3,8,235,236,238,240,247,264,275,276],larg:[20,24,31,89,99,100,222,223,243],large_system_test:267,large_unlink_test:267,large_write_test:267,larger:[10,31,89,226],largest:[89,244],las_app_port:264,las_app_tx:264,las_join:264,las_link_chk:264,las_rd_app_eui:264,las_rd_app_kei:264,las_rd_dev_eui:264,las_rd_mib:264,las_wr_app_eui:264,las_wr_app_kei:264,las_wr_dev_eui:264,las_wr_mib:264,last:[20,26,72,77,89,90,97,99,128,148,179,193,201,206,214,219,225,249,253,254,255,256,264,268,276,278,280,282],last_checkin:[77,285,288],last_n_off:148,last_op:187,last_read_tim:208,latenc:27,later:[7,8,72,84,89,128,231,240,241,242,246,252,256,264,267,276,282,289,290],latest:[1,2,4,7,10,11,49,52,55,56,60,79,83,129,235,256,268,269,270,275,276],latex:[173,179],latter:[20,89,132,173],launch:12,launchpad:4,law:[241,242,256,275,276,282,289,290],layer:[9,20,21,89,90,95,96,134,152,162,165,173,180,193,208,209,225,238,248,276,292],layout:[96,128,174,288],lc_f:207,lc_pull_up_disc:207,lc_rate:207,lc_s_mask:207,lcheck:275,ld4:260,ldebug:224,ldflag:50,ldr:262,le_elem_off:145,lead:[89,92,252,276],leadingspac:89,leak:[160,161],learn:[7,26,61,235,240,257,284],least:[22,89,97,128,179,190,192,236,258,264,276,292],leav:[89,135,148,222],led1:[238,261],led2:238,led3:238,led:[1,7,61,93,96,99,134,181,186,236,238,243,247,256,257,258,259,260,261,262,263,268,275,276,278,285,288,292],led_blink_pin:[93,99,240,243,258],led_blink_pin_1:240,led_blink_pin_2:240,led_blink_pin_3:240,led_blink_pin_4:240,led_blink_pin_5:240,led_blink_pin_6:240,led_blink_pin_7:240,led_blink_pin_8:240,led_pin:240,left:[86,90,99,145,198,222,262,274,282,292],legaci:[30,151,225,243],len:[89,135,140,141,162,163,170,171,172,187,190,199,204,251,264,275],length:[20,21,27,89,93,128,130,140,156,157,176,179,182,198,251,264],less:[92,101,128,179,253,254,255],lesser:179,lesson:[243,292],let:[4,8,55,89,93,205,222,223,235,243,246,248,249,250,251,252,253,254,255,258,262,267,269,270,274,275,276,282],level:[1,2,9,14,18,20,23,27,29,30,31,32,34,35,37,38,39,40,41,42,43,44,45,46,47,48,49,50,51,52,53,54,55,57,58,59,61,62,64,65,66,67,68,69,70,71,72,73,74,75,76,77,80,81,82,89,91,93,131,134,135,152,173,174,181,208,224,225,234,250,251,254,255,256,260,264,267,268,270,274,275,276],level_list:72,leverag:[132,134,245,276],lflag:[1,50,61],lib:[1,4,45,53,55,82,101,130,152,180,224,225,275,276],libc6:6,libc:[7,93,101],libc_baselibc:[222,262],libftdi1:4,libftdi:4,libg:48,libgcc:[48,222],libhidapi:4,librari:[1,4,48,50,55,58,81,87,89,93,94,96,101,128,130,134,152,160,180,181,195,222,223,231,246,267,269,270,275,276,277],libusb:4,libusb_error_access:260,libusb_open:260,licens:[4,7,11,55,61,101,134,241,242,246,256,260,262,263,268,269,275,276,282,289,290],lieu:66,life:[24,254],light:[9,31,181,206,235,238,240,257,260,261,262,263,277,278,285,288],lightblu:[250,274,276],lightweight:151,like:[2,3,5,8,12,31,55,58,59,62,81,82,89,92,93,96,97,98,101,128,130,134,140,181,187,223,235,240,241,242,246,256,260,262,267,269,275,276,277,279,280,282,284,288,289,290],likewis:[62,179],limit:[3,20,27,29,99,101,135,151,215,219,222,236,241,249,254,275,276,289],limt:223,line:[2,6,7,10,12,36,38,39,47,62,93,101,130,186,223,229,235,240,241,247,253,258,260,261,269,271,275,276,277,278,282,289],linear:179,linearacc:278,lines_queu:130,link:[2,3,7,20,21,22,27,34,38,42,60,61,81,83,85,89,179,192,214,222,225,231,234,235,241,242,246,247,250,255,256,258,259,260,261,262,263,264,268,275,276,278,282,285,286,288,289,290,292],linker:[1,61,94,101,222,246,262],linkerscript:[61,93],linux:[5,7,9,12,56,66,78,79,135,239,247,256,258,259,260,262,263,268,278,285,286,287,288],liquid:276,lis2dh12:[207,282],lis2dh12_0:[207,282],lis2dh12_cfg:207,lis2dh12_config:207,lis2dh12_data_rate_hn_1344hz_l_5376hz:207,lis2dh12_fs_2g:207,lis2dh12_init:207,lis2dh12_onb:282,list:[3,6,7,8,12,22,27,29,34,35,48,50,51,53,57,59,61,66,71,72,73,75,76,77,78,80,85,87,89,90,93,94,95,99,128,130,131,134,136,179,180,192,205,214,223,225,226,229,234,235,239,240,246,249,252,253,256,257,258,259,260,261,262,263,264,269,270,275,276,280,285,286,288,292],listen:[2,14,30,31,66,89,206,211,222,249],listener_cb:282,lit:[236,240,243,247],littl:[6,20,23,89,128,235,240,246,253,264,270,275],live:[134,235,252,253,256,268,269,270],lma:262,lmp:20,load:[2,4,5,7,12,34,39,43,47,55,57,58,59,61,93,128,129,191,222,235,238,239,240,241,242,243,250,257,258,264,270,274,275,276,289,290],load_arduino_blinki:12,load_arduino_boot:12,loader:[10,43,50,93,128,130,191,256,259,260,261,263,268,278,285,286,288],loc:[141,145,150],local:[1,4,6,7,10,11,20,27,28,36,40,49,55,58,60,71,81,83,94,99,100,244,249,256,268,280],localhost:[66,241,282,289],locat:[1,8,11,19,31,61,89,93,128,140,145,179,187,231,243,253,258,262,268,269,275,278,285,286,288],lock:[9,88,92,98,140,206,211,238],log:[1,7,10,34,35,37,38,39,40,41,42,43,44,45,46,47,48,49,50,51,52,53,54,57,58,59,62,64,65,66,67,68,69,70,71,73,74,75,76,77,78,80,81,82,128,131,132,150,159,166,180,181,214,222,224,225,235,236,241,246,256,259,260,262,263,265,275,276,280,282,286,289],log_cbm_handl:205,log_cbmem_handl:205,log_cli:[214,265],log_console_handl:[205,208],log_debug:205,log_error:208,log_fcb:225,log_fcb_handl:205,log_handl:205,log_info:208,log_init:225,log_level:[50,205,225,239,265],log_level_debug:205,log_level_error:205,log_module_bno055:208,log_module_default:205,log_nam:72,log_newmgr:224,log_newtmgr:[50,224,225,236],log_nmgr_register_group:225,log_regist:[205,208],log_shel:235,log_syslevel:[205,208],logic:[1,21,23,29,128,174,193,264,275],login:271,loglevel:[1,34,35,37,38,39,40,41,42,43,44,45,46,47,48,49,50,51,52,53,54,57,58,59,62,64,65,66,67,68,69,70,71,72,73,74,75,76,77,80,81,82,275],logxi:81,long_filename_test:267,longer:[3,8,11,21,24,90,210,224,247,275,277],longjmp:233,longrange_interv:27,longrange_pass:27,longrange_window:27,look:[8,10,24,55,61,93,95,99,101,128,130,131,187,199,204,222,223,235,240,243,244,249,251,252,253,267,270,272,274,275,276,280,282,292],lookup:[211,220,251,282],loop:[84,87,92,99,154,155,156,161,164,225,236,243,246,258,274,275,276],lora:264,lora_app_shel:264,lora_app_shell_telee02:264,lora_app_shell_telee0:264,lora_mac_timer_num:264,lose:26,loss:[26,29,182],lost:[97,179],lost_found_test:267,lot:[7,222,224,249,267,276],low:[9,20,21,22,31,86,89,93,98,135,152,181,186,190,191,208,243,251,254,255,256,257,260,268,292],lower:[20,86,91,92,98,99,224,225,239,243,248,258,262],lowest:[73,85,90,99,179,225,243],lowpow:278,lru:179,lrwxr:[4,81],lsb:187,lst:[34,55,61],ltbase:225,ltd:27,ltk:27,ltk_sc:27,ltrequir:225,lua:[137,138,139],lua_cmd:139,luckili:275,m32:6,m4g:278,mac:[3,5,7,9,12,20,55,56,78,79,235,239,240,247,250,256,258,259,260,262,263,264,268,274,276,278,285,286,287,288],machin:[2,3,7,8,94,247,292],maco:[4,66],macro:[20,89,90,93,97,199,206,208,223,225,231,243,253,267,276],made:[2,10,11,20,55,71,99,128,187,243,244,264,276],mag:278,mag_rev:278,maggyro:278,magic:[61,128,140,179],magnet:[206,278],magnetomet:208,mai:[2,4,6,7,8,12,22,27,29,30,31,51,53,57,58,62,80,81,82,85,87,89,90,92,93,96,101,128,130,132,134,161,179,181,186,187,192,205,206,207,208,210,211,222,223,224,225,226,229,231,236,241,243,246,247,256,258,259,260,261,262,263,264,268,269,275,276,278,282,285,288,289],mail:[3,10,134,234,235,240,246,257,276,292],main:[7,12,26,31,57,61,77,80,87,89,92,95,99,128,130,138,176,177,197,206,211,214,216,221,225,230,232,236,238,240,246,249,254,255,256,259,260,261,262,263,267,274,275,276,278,285,286,288],mainli:222,maintain:[4,49,85,128,134,179,206,211,225,267,269,270],mainten:[132,223],major:[55,61,96,197,243,255,269,270],major_num:[269,270],make:[1,2,3,7,8,9,19,20,21,24,30,31,33,55,57,63,71,85,89,90,93,128,134,140,141,173,179,181,198,205,222,223,235,239,240,243,245,246,247,249,251,252,254,255,256,258,262,264,267,269,274,275,276,277,282,292],makerbeacon:236,malloc:[88,90,93,101,243,276],man:[6,27,101],manag:[6,8,16,17,21,27,31,39,45,57,58,59,61,64,66,68,71,72,73,76,77,80,81,82,87,90,92,93,94,96,99,128,130,134,181,196,199,206,208,209,210,222,225,239,258,259,265,268,270,278,282,285,287,288,292],mandatori:[20,93,226,253,254,255],mani:[20,31,55,61,89,93,95,128,140,148,160,161,181,192,251,256,269],manifest:[34,37,43,55,61,235,236,240,275],manipul:[1,39,45,89],manner:[27,29,89,92,128,181],manual:[21,25,60,83,90,92,99,101,173,222,229,235,241,242,256,262,282,288,289,290],manufactur:[19,27,29,39,43,57,58,59,66,222,249,256,268],many_children_test:267,map:[2,3,8,20,27,28,61,96,134,135,160,181,185,186,193,199,222,224,225,241,251,258,268,269,270,278,285,288,289],mar:[100,259,261,264,276,282],march:68,mark:[27,28,71,93,262],marker:93,market:[31,261],mask:[27,206,208,210,211,280,282],mass:[247,260],mass_eras:[259,260],master:[1,7,11,27,56,57,59,60,79,80,82,83,134,181,183,187,190,244,256,268,269,270],match:[2,7,20,93,94,96,128,210,211,222,256,260,268,269,270],matter:10,max:[156,198,199],max_cbmem_buf:205,max_conn_event_len:27,max_ev:27,max_len:[156,162,182],max_protohdr:89,maxim:9,maximum:[21,27,29,89,128,130,173,175,179,182,198,214,215,219,241,267,289],mayb:[241,242,289,290],mb_crc:275,mb_crc_check:275,mb_crc_tbl:275,mbed:[259,263],mbedtl:[7,256,259,261,263,268,285,286,288],mblehciproj:247,mblen:89,mbuf:[92,199,279],mbuf_buf_s:89,mbuf_memblock_overhead:89,mbuf_memblock_s:89,mbuf_mempool_s:89,mbuf_num_mbuf:89,mbuf_payload_s:89,mbuf_pkthdr_overhead:89,mbuf_pool:89,mbuf_usage_example1:89,mbuf_usage_example2:89,mcu:[7,9,53,94,97,134,135,181,186,189,190,191,192,193,195,235,240,243,256,259,268,282],mcu_gpio_porta:135,mcu_sim_parse_arg:[258,282],mdw:262,mean:[2,12,20,89,91,97,98,99,100,128,135,175,190,201,203,225,233,253,260,270,275,276],meaning:[138,193],meant:[1,97,129],measur:[9,243,264],mechan:[1,22,92,222,225,238,269,271,275,276],medic:[21,55],medium:167,meet:[207,239,247,256,257,259,260,261,262,263,278,280,281,282,284,285,286,287,288],mem:[7,225],member:[84,87,89,90,91,97,98,99,100,130,187,190,192,249,251],membuf:90,memcmp:89,memcpi:251,memori:[9,20,48,73,87,88,89,92,93,96,97,101,128,132,134,135,151,167,173,174,178,179,181,182,184,187,215,219,224,236,238,241,243,251,262,264,265,286,289],mempool:[64,80,81,82,89,90,214,275],memset:[207,249,252,255,276],mention:[12,179,206,276],menu:[12,59,260,262,288],merchant:4,merci:90,merg:244,mesh:32,messag:[2,4,22,31,42,57,58,59,75,130,132,133,166,214,217,218,226,238,256,260,264,268,275],messi:276,messsag:62,met:[20,236,238,268],meta:[8,268,278],metadata:[43,128,167],meter:21,method:[25,89,99,133,173,183,186,190,205,214,223,251,269],mfg:[7,39,57,58,59,70,225],mfg_data:29,mfg_init:225,mgmt:[7,130,132,190,196,214,224,225,236,275,276],mgmt_evq_set:236,mgmt_group_id_config:131,mgmt_group_id_crash:131,mgmt_group_id_default:131,mgmt_group_id_imag:131,mgmt_group_id_log:131,mgmt_group_id_runtest:131,mgmt_group_id_stat:131,mgmt_imgmgr:222,mgmt_newtmgr_nmgr_o:222,mgutz:81,mhz:[21,24],mib:[55,81,264],mic:20,micro:[55,239,241,242,243,256,257,259,261,262,264,268,276,278,284,285,287,288,289,290],microcontrol:[9,101,128,262,288],microsecond:[24,86,100],microsoft:12,mid:[14,128,260],middl:[27,128,179,276],might:[1,2,18,20,61,93,96,130,134,179,181,187,208,222,224,241,242,246,248,249,254,255,256,260,269,270,272,282,289,290],migrat:[179,225],milisecond:27,millisecond:[27,100,264],millivolt:276,min:[72,73,128,268,286],min_conn_event_len:27,mind:[97,246],mingw32:59,mingw64:59,mingw:[4,7,8,12,56,82,258,268,278,285,288],mini:260,minicom:[8,258,268,275,278],minim:[93,134,151,152,173,179,208,246],minimum:[27,29,72,89,90,128,179,246],minor:[197,255,269,270],minor_num:[269,270],minu:89,minut:[81,100,254,267],mip:[7,61],mirror:[1,10,11,269,275,276],misc:278,mislead:6,mismatch:[20,89],miso:190,miso_pin:[135,136],miss:[20,57,93,224,235,240,246,257,276],misspel:224,mitm:27,mk64f12:[134,181],mkdir:[11,43,80,82,93,235,256,259,260,261,262,263,264,268,269,275,276],mkdir_test:267,mkdoc:244,mkr1000:266,mkr1000_boot:268,mkr1000_wifi:268,mlme:264,mman:57,mmc0:[136,152],mmc:151,mmc_addr_error:136,mmc_card_error:136,mmc_crc_error:136,mmc_device_error:136,mmc_erase_error:136,mmc_init:136,mmc_invalid_command:136,mmc_ok:136,mmc_op:[136,152],mmc_param_error:136,mmc_read_error:136,mmc_response_error:136,mmc_timeout:136,mmc_voltage_error:136,mmc_write_error:136,mn_socket:7,mobil:31,mod:[30,250],modbu:275,mode:[9,20,22,27,29,134,158,160,167,168,170,181,182,186,190,193,208,222,249,256,260,262,267,278],model:[21,22,32,87,195,259],modern:[8,151],modif:[11,235,267,277],modifi:[6,62,89,93,100,133,192,240,243,275,276,281,284],modul:[72,86,90,92,101,132,137,205,215,219,221,258,264,288],module_list:72,module_nam:[219,221],modulo:100,moment:[135,187,195,251,270],mon:[256,259,260],monitor:[89,130,132,140,212,223,262,277,284,292],monolith:253,month:267,more:[1,4,7,9,10,12,20,21,22,29,30,34,35,39,43,51,53,57,58,59,61,62,64,80,81,82,85,87,89,92,93,98,99,100,101,128,129,134,141,145,152,163,164,179,190,193,199,205,206,207,208,209,214,222,225,226,239,240,241,243,246,249,253,254,255,256,258,259,264,267,268,270,274,275,276,278,282,285,288,289,292],mosi:190,mosi_pin:[135,136],most:[1,8,14,19,21,23,24,25,61,89,93,94,99,101,128,179,183,190,222,224,243,249,267,274,275,276,278,280,282],mostli:[6,9,222,254,255],motor:9,mou:244,mount:[165,276],mous:[134,181],move:[8,45,57,58,59,81,92,100,128,166,182,222,258,262,276,277,279,282],mp_block_siz:90,mp_flag:90,mp_membuf_addr:90,mp_min_fre:90,mp_num_block:90,mp_num_fre:90,mpe:90,mpool:[219,264],mpstat:[64,78,80,81,82,131,133,236,286],mq_ev:89,mqeueue:89,msb:187,msdo:93,msec:[27,194],msg:229,msg_data:27,msp:[256,262],msy:59,msys2:56,msys2_path_typ:59,msys64:59,msys_1:[73,286],msys_1_block_count:[277,279],msys_1_block_s:[277,279],mtd:135,mtu:[10,20,27,28,250],mu_level:91,mu_own:91,mu_prio:91,much:[89,93,98,101,146,179,275],multi:[1,9,50,62,96,99,187],multilib:[6,7,57],multipl:[4,23,27,29,34,35,50,51,55,84,91,92,97,101,129,132,134,181,190,211,225,249,253,254,269],multiplex:21,multiplexor:96,multipli:[90,243],multitask:[92,243],must:[1,2,4,5,7,8,9,11,12,14,22,24,25,33,37,41,46,53,55,57,59,61,63,66,68,71,80,86,87,89,90,92,93,96,97,99,128,129,130,136,140,148,152,159,160,162,166,173,174,175,176,178,179,180,187,190,192,193,197,198,199,205,206,207,208,210,211,212,214,215,216,219,223,224,225,232,235,236,239,241,243,246,249,251,258,261,262,264,268,269,270,275,276,278,279,280,281,282,285,288,289],mutex:[88,92,98,99],mutual:91,my_at45db_dev:135,my_blinki:50,my_blinky_sim:[7,34,35,43,55,61,246,247,259,260,275],my_blocking_enc_proc:20,my_callout:238,my_conf:129,my_config_nam:225,my_driv:[275,276],my_ev_cb:238,my_eventq:236,my_gpio_irq:238,my_interrupt_ev_cb:238,my_memory_buff:90,my_new_target:50,my_newt_target:50,my_packag:205,my_package_log:205,my_pool:90,my_proj1:246,my_proj:246,my_project:[1,256,268,269,276],my_protocol_head:89,my_protocol_typ:89,my_result_mv:276,my_sensor:282,my_sensor_devic:282,my_sensor_poll_tim:282,my_stack_s:99,my_stat:223,my_stat_sect:223,my_target1:62,my_task:99,my_task_evq:89,my_task_func:99,my_task_handl:89,my_task_pri:99,my_task_prio:99,my_task_rx_data_func:89,my_task_stack:99,my_timer_ev_cb:238,my_timer_interrupt_eventq:238,my_timer_interrupt_task:238,my_timer_interrupt_task_prio:238,my_timer_interrupt_task_stack:238,my_timer_interrupt_task_stack_sz:238,my_timer_interrupt_task_str:238,my_uart:193,myadc:276,myapp1:[241,289],myapp:223,myapp_cmd:220,myapp_cmd_handl:220,myapp_console_buf:130,myapp_console_ev:130,myapp_init:130,myapp_process_input:130,myapp_shell_init:220,mybl:[34,35,46,50,66,73,76,77,236],myble2:[37,38,247],myblehostd:66,mybleprph:[66,239],mybletyp:66,myboard:[45,93],myboard_debug:93,myboard_download:93,mycmd:221,myconn:236,mycor:71,mydata:89,mydata_length:89,mylora:264,mymcu:95,mymfg:70,mymodul:97,mymodule_has_buff:97,mymodule_perform_sanity_check:97,mymodule_register_sanity_check:97,mynewt:[1,3,4,5,6,11,13,20,21,25,30,32,37,38,39,43,44,50,51,53,55,56,57,59,60,61,62,71,78,79,80,82,83,84,86,87,88,97,98,99,100,101,128,129,132,133,134,151,152,173,180,181,182,183,186,187,190,193,205,208,214,216,222,223,224,225,231,234,235,236,238,239,241,242,243,245,247,248,250,254,255,256,257,258,259,260,261,262,263,264,265,267,268,270,274,275,276,278,281,282,285,286,287,288,289,290,292],mynewt_0_8_0_b2_tag:[269,270],mynewt_0_8_0_tag:269,mynewt_0_9_0_tag:269,mynewt_1_0_0_b1_tag:269,mynewt_1_0_0_b2_tag:269,mynewt_1_0_0_rc1_tag:269,mynewt_1_0_0_tag:269,mynewt_1_3_0_tag:[57,59,80,82],mynewt_arduino_zero:[256,268,269],mynewt_nord:276,mynewt_stm32f3:235,mynewt_v:[130,214,219,223,225,267,276],mynewt_val_:225,mynewt_val_log_level:225,mynewt_val_log_newtmgr:225,mynewt_val_msys_1_block_count:225,mynewt_val_msys_1_block_s:225,mynewt_val_my_config_nam:225,mynewtl:277,mynewtsan:75,myperiph:[239,250],mypool:90,myproj2:222,myproj:[2,7,12,93,235,239,240,242,256,258,259,260,261,262,263,269,275,277,278,282,290],myriad:9,myseri:[73,76,77],myserial01:66,myserial02:66,myserial03:66,mytask:243,mytask_handl:243,mytask_prio:243,mytask_stack:243,mytask_stack_s:243,myudp5683:66,myvar:65,n_sampl:278,nad_flash_id:174,nad_length:174,nad_offset:174,nak:187,name1:50,name2:50,name:[1,2,4,7,8,10,11,12,20,21,27,29,34,35,37,38,42,43,44,45,47,48,50,51,53,55,57,58,59,61,62,64,65,66,67,68,69,70,71,72,73,74,75,76,77,80,81,82,90,93,94,95,97,99,100,101,129,130,134,152,154,155,156,159,160,161,164,180,181,186,198,199,200,202,204,205,206,207,208,209,211,215,219,220,221,222,224,227,228,230,235,236,238,241,243,246,249,251,253,254,255,256,258,259,260,261,262,263,267,268,269,270,271,275,276,277,278,279,282,285,286,288,289],name_is_complet:249,name_len:[154,155,156,161,164,249],namespac:[88,129,214,254],nano2:[43,53,93,263],nano2_debug:[93,263],nano:[257,292],nanosecond:[86,192],nativ:[2,3,7,12,43,50,53,55,59,61,66,190,224,225,235,238,247,259,260,268,275,276,286,292],natur:[93,179],navig:[10,292],nb_data_len:179,nb_hash_entri:179,nb_inode_entri:179,nb_prev:179,nb_seq:179,nbuf:89,nc_num_block:175,nc_num_cache_block:175,nc_num_cache_inod:175,nc_num_fil:175,nc_num_inod:175,ncb_block:179,ncb_file_offset:179,ncb_link:179,ncheck:275,nci_block_list:179,nci_file_s:179,nci_inod:179,nci_link:179,nda_gc_seq:179,nda_id:179,nda_length:179,nda_mag:179,nda_ver:179,ndb_crc16:179,ndb_data_len:179,ndb_id:179,ndb_inode_id:179,ndb_magic:179,ndb_prev_id:179,ndb_seq:179,ndi_crc16:179,ndi_filename_len:179,ndi_id:179,ndi_mag:179,ndi_parent_id:179,ndi_seq:179,nding:253,ndof:278,ndof_fmc_off:278,nearest:259,neatli:249,necessari:[6,24,39,47,57,58,59,89,128,152,179,233,235,246,251,256,264,267,276],need:[4,5,6,7,8,9,10,11,12,14,23,24,32,43,50,52,55,57,58,59,60,61,64,66,80,81,83,84,88,89,90,91,92,93,95,96,97,98,99,128,130,135,140,141,142,152,179,191,194,205,206,208,209,210,211,214,220,222,223,224,225,229,236,238,239,243,246,247,249,251,252,253,254,255,256,258,259,260,261,262,263,267,268,270,271,274,277,279,282,285,286,288],neg:[89,100,179,253],neither:89,ness:190,nest:[91,159],net:[4,7,24,51,212,225,246,247,251,253,268,275,276,277,279,281],net_nimble_control:222,net_nimble_host:222,network:[1,9,23,27,31,32,55,89,92,222,243,264,268],never:[19,92,97,99,166,179,225,243,246,251],nevq:87,new_bletini:45,new_pool:89,new_slinki:45,newer:6,newest:[140,224,243],newli:[1,10,19,43,128,160,247,254,255,269],newlib:101,newlin:130,newt:[1,3,5,6,7,13,32,56,61,62,73,76,77,80,81,82,83,92,93,94,96,134,222,223,224,225,231,235,237,238,239,240,241,242,243,245,246,247,250,254,255,256,257,258,259,260,261,262,263,264,265,267,268,269,270,271,272,275,276,277,278,279,280,282,284,285,286,287,288,289,290,292],newt_1:[57,60],newt_1_1_0_windows_amd64:60,newt_1_3_0_windows_amd64:59,newt_group:2,newt_host:2,newt_us:2,newtgmr:[81,82,83],newtmgr:[1,7,9,10,13,57,58,59,63,64,78,79,130,131,133,195,205,217,218,222,224,225,238,275,276,287,292],newtmgr_1:[80,83],newtmgr_1_1_0_windows_amd64:83,newtmgr_1_3_0_windows_amd64:82,newtmgr_shel:214,newtron:[152,180,224,225],newtvm:11,next:[7,8,24,30,71,77,82,85,89,90,99,128,130,132,140,145,154,155,156,161,164,179,195,199,206,210,211,222,225,233,239,240,243,244,246,249,253,254,255,256,259,262,270,274,275,276],next_checkin:[77,285,288],nff:[7,101,135,152,174,175,176,177,178,180,188,224,225,231,267],nffs_area_desc:[173,176,177,226],nffs_area_mag:179,nffs_area_max:[176,177],nffs_block:179,nffs_block_cache_entri:179,nffs_block_cache_list:179,nffs_block_mag:179,nffs_cache_block:179,nffs_cache_block_list:179,nffs_cache_inod:179,nffs_close:180,nffs_closedir:180,nffs_detect:[177,179],nffs_detect_fail:[152,173],nffs_dirent_is_dir:180,nffs_dirent_nam:180,nffs_disk_area:179,nffs_disk_block:179,nffs_disk_inod:179,nffs_file_len:180,nffs_flash:188,nffs_flash_area:[224,225],nffs_format:[176,179,226],nffs_getpo:180,nffs_hash_entri:179,nffs_id_non:179,nffs_init:[175,176,177,180],nffs_inod:179,nffs_inode_entri:179,nffs_inode_list:179,nffs_inode_mag:179,nffs_intern:173,nffs_mkdir:180,nffs_op:180,nffs_open:180,nffs_opendir:180,nffs_read:180,nffs_readdir:180,nffs_renam:180,nffs_seek:180,nffs_short_filename_len:179,nffs_test:267,nffs_test_debug:267,nffs_test_priv:267,nffs_test_system_01:267,nffs_test_unlink:226,nffs_test_util:267,nffs_unlink:180,nffs_write:180,nhe_flash_loc:179,nhe_id:179,nhe_next:179,ni_filenam:179,ni_filename_len:179,ni_inode_entri:179,ni_par:179,ni_seq:179,nice:[223,274],nie_child_list:179,nie_hash_entri:179,nie_last_block_entri:179,nie_refcnt:179,nie_sibling_next:179,nil:67,nim:253,nimbl:[7,23,24,26,29,66,225,236,239,245,248,249,250,251,252,253,275,276,277,279],njb:[200,201,202,203,204],njb_buf:204,njb_enc:202,nlip:217,nmgr:133,nmgr_def_taskstat_read:202,nmgr_err_eok:202,nmgr_jbuf:[200,201,202,203,204],nmgr_o:131,nmgr_shell:[130,225,236],nmgr_shell_in:217,nmgr_shell_out:218,nmgr_shell_pkg_init:225,nmgr_task_init:217,nmgr_transport:218,nmgr_uart:236,nmgr_urart_spe:236,nmxact:11,no_of_sampl:278,no_rsp:28,no_wl:[27,30],no_wl_inita:27,node:[21,32,55,154,155,156,161,164,179],nodefault:[199,204],nodup:27,nogdb:[38,47],noinputnooutput:27,non:[7,18,19,21,24,27,31,32,84,89,90,99,100,144,148,150,179,182,186,187,190,191,192,193,215,217,218,219,222,225,254,255,264,269,282],none:[4,7,8,12,20,27,30,82,87,93,101,128,179,216,220,221,222,226,229,235,241,242,256,260,264,276,282,289,290],nonexist:[160,179],nonsens:267,nonzero:[89,141,142,143,145,146,149,150,190,227,228,230,232,233,252,267],nor:22,nordic:[23,93,134,181,185,189,191,238,239,259,261,275,276,278,282,287,292],nordicsemi:[259,261,264,276,282],normal:[2,98,179,229,231,274,278],notat:[55,262],note:[1,2,4,6,7,10,11,12,21,22,23,24,29,32,43,47,50,57,58,59,60,61,66,68,71,80,81,82,83,85,86,87,89,90,91,92,93,94,99,128,130,136,173,187,190,192,195,206,207,208,209,211,214,215,219,222,224,225,235,236,239,241,243,244,246,247,249,251,253,254,255,256,258,259,260,261,262,263,264,265,268,269,270,271,275,277,278,279,280,282,284,285,286,288,289,292],noth:[11,179,226,254,255,275,276],notic:[7,11,55,61,92,93,180,222,243,246,270,274,275,276],notif:[10,27,28,87,130,210,248,274],notifi:[10,28,210,252,253],notnul:225,nov:8,now:[2,8,9,59,86,89,90,91,93,98,99,128,151,153,157,160,163,166,168,170,179,186,193,222,235,236,239,240,241,242,243,246,248,249,250,252,253,254,255,256,259,264,267,269,274,275,276,278,282,286,289,290],nreset:256,nrf51:[24,53,93,134,181,265],nrf51dk:[53,222],nrf51xxx:189,nrf52840pdk:32,nrf52:[4,24,61,93,134,181,185,191,207,238,239,241,242,247,257,258,259,264,275,277,279,282,287,289,290,292],nrf52_adc_dev_init:276,nrf52_bleprph_oic_bno055:277,nrf52_blinki:[241,258,261,263,289],nrf52_bno055_oic_test:[277,279],nrf52_bno055_test:[278,280],nrf52_boot:[236,247,261,276,277,278,279,285],nrf52_hal:93,nrf52_slinki:285,nrf52_thingi:207,nrf52dk:[37,38,53,61,62,93,225,238,246,247,250,258,261,276,277,278,279,285],nrf52dk_debug:[61,93,258],nrf52dk_download:93,nrf52k_flash_dev:[93,185],nrf52pdk:[247,261],nrf52serial:285,nrf52xxx:[48,93,191,259,282],nrf5x:24,nrf:[25,276],nrf_drv_saadc:276,nrf_drv_saadc_config_t:276,nrf_drv_saadc_default_channel_config_s:276,nrf_drv_saadc_default_config:276,nrf_saadc_channel_config_t:276,nrf_saadc_gain1_6:276,nrf_saadc_input_ain1:276,nrf_saadc_reference_intern:276,nrf_saadc_typ:276,nrpa:[19,254,255],nsampl:278,nsec:86,nth:179,ntoh:89,ntohl:89,ntrst:256,nucleo:53,nul:179,num_block:90,num_byt:184,number:[1,8,9,10,22,27,34,35,37,38,39,40,41,42,43,44,45,46,47,48,49,50,51,52,53,54,57,58,59,60,61,62,64,65,66,67,68,69,70,71,72,73,74,75,76,77,80,81,82,83,84,86,87,89,90,91,92,93,98,99,100,101,128,129,139,140,141,151,157,163,168,170,171,172,173,174,175,179,182,186,187,189,190,192,193,195,197,198,199,206,214,215,219,223,224,225,229,236,238,239,241,243,247,253,254,255,256,258,262,264,268,269,270,274,275,276,278,279,285,288,289],numer:[20,22,85,93,128],nvm:256,nxp:[134,181],objcopi:6,objdump:6,object:[4,11,48,55,61,81,86,92,93,96,99,132,166,199,201,202,203,208,210,211,252,267,278,281],objsiz:[6,48,222],observ:[14,27,212,247,281],obtain:[27,89,91,98,99,179,192,269,275,276],obvious:53,oc_add_devic:277,oc_add_resourc:277,oc_app_resourc:[277,279],oc_get:277,oc_if_rw:277,oc_init_platform:277,oc_main_init:[212,277],oc_new_resourc:277,oc_put:277,oc_resource_bind_resource_interfac:277,oc_resource_bind_resource_typ:277,oc_resource_set_default_interfac:277,oc_resource_set_discover:277,oc_resource_set_periodic_observ:277,oc_resource_set_request_handl:277,oc_serv:[212,236,277,279,281],oc_transport_gatt:236,oc_transport_ip:236,oc_transport_seri:236,occasion:89,occur:[26,27,89,91,100,186,187,190,224,251,252,254,255],occurr:225,ocf:132,ocf_sampl:[7,61],ocimgr:131,ock:211,oct:275,octet:[27,29,31,128],od_init:134,od_nam:208,odd:193,off:[2,20,21,31,32,84,87,89,96,97,99,130,134,140,181,182,187,204,206,208,209,213,236,238,239,240,246,247,254,255,258,262,277,279,280,281,282,284,292],off_attr:204,offer:[1,21,132,134,151,184,276],offset1:89,offset2:89,offset:[20,28,71,89,93,100,128,140,148,152,158,162,167,168,170,171,172,174,179,199,222,224,225,278],often:[9,55,93,179,187,190],ohm:276,oic:[7,51,66,132,209,210,282,292],oic_bhd:66,oic_bl:66,oic_seri:66,oic_udp:66,oic_udpconnstr:66,oicmgr:[7,66,131,132,133],old:[45,140],older:[10,59,82,260],oldest:[140,145,149,224],olimex:[257,275,287,292],olimex_blinki:262,olimex_stm32:[53,262,288],om1:89,om2:89,om_data:89,om_databuf:89,om_flag:89,om_len:89,om_omp:89,om_pkthdr_len:89,ome:90,omgr:133,omi_block_s:90,omi_min_fre:90,omi_nam:90,omi_num_block:90,omi_num_fre:90,omit:[47,224],omp:89,omp_databuf_len:89,omp_flag:89,omp_len:89,omp_next:89,omp_pool:89,on_reset:26,on_sync:26,onboard:[208,209,241,242,280,284,289,290,292],onc:[19,29,55,57,61,80,84,86,89,90,91,92,99,128,143,181,190,192,233,235,236,239,240,249,254,257,258,264,269,275,276],one:[1,4,7,8,10,11,12,19,20,21,22,23,27,29,30,31,34,35,39,43,45,50,51,53,57,58,59,61,67,85,87,89,91,92,93,96,98,99,128,129,130,136,137,140,152,165,166,173,174,176,177,179,182,187,190,195,205,206,210,211,220,222,223,224,225,240,243,244,246,247,253,254,255,256,257,258,259,260,261,262,263,264,267,268,269,270,271,274,275,276,278,284,285,288,292],ones:[14,89,98,134,181,205,247,292],ongo:27,onli:[1,2,7,8,10,11,12,14,19,20,24,27,29,31,34,35,37,38,39,40,41,42,43,44,45,46,47,48,49,50,51,52,53,54,55,57,58,59,60,61,62,66,72,80,83,86,87,89,90,92,93,96,97,98,128,129,130,131,134,135,136,138,150,152,154,155,156,158,161,164,165,167,168,173,174,179,187,190,195,205,206,208,209,211,214,219,222,223,224,225,228,229,231,232,234,236,239,240,243,244,249,251,254,256,258,264,265,267,268,269,270,271,275,276,277,278,281,282,286],onlin:[241,242,256,282,289,290],onto:[1,20,42,43,47,84,87,89,93,257,259,260,261,262,263,274,275,278,285,288],oob:[20,27,29],opaqu:[152,192,205,206,208,210,282],open:[4,8,9,10,12,20,21,38,39,47,55,57,58,59,61,96,132,134,152,153,157,158,160,161,163,164,167,168,169,170,171,172,175,179,207,254,256,259,260,262,263,267,275,280,286],open_test:267,openocd:[12,93,256,259,260,262,263,288],openocd_debug:[259,275],oper:[1,9,12,15,18,20,21,26,31,39,57,58,59,84,89,96,97,98,99,100,130,132,134,152,160,161,162,167,169,173,174,178,179,180,181,182,184,186,193,206,211,223,225,234,246,247,251,252,253,254,255,256,264,267,268,270,271,274,275,278,282],oppos:[31,89,271],opt:4,optim:[1,24,32,37,38,43,50,61,89,93,94,101,134,222,235,243,246,247,250,256,259,260,261,262,263,264,268,275,276,278,282,285,288],optimis:31,option:[2,3,4,6,7,8,10,12,22,23,27,36,37,46,51,55,62,66,72,84,87,90,93,128,132,134,150,151,197,206,208,209,214,222,224,225,226,231,244,246,247,253,256,260,262,264,268,269,270,275,276,278,288],orang:[259,263],order:[1,8,9,22,33,55,61,63,85,87,89,90,91,97,99,101,128,129,132,179,190,206,224,225,236,240,241,242,243,264,267,270,272,275,276,282,289,290],org:[1,4,10,11,39,57,58,59,61,80,82,101,130,137,241,242,254,256,259,260,262,263,267,275,276,282,289,290],organ:[11,134,223,267,269],origin:[11,46,93,128,262,275],os_align:[89,90],os_arch:[61,90,100],os_bad_mutex:91,os_bsp_adc0:276,os_bsp_adc0_config:276,os_callout:[61,84,97,129,238,258,282],os_callout_f_queu:84,os_callout_func:[84,89],os_callout_func_init:84,os_callout_init:[84,97,238,258,282],os_callout_queu:84,os_callout_remaining_tick:84,os_callout_reset:[84,97,238,258,282],os_callout_stop:84,os_cfg:61,os_cli:225,os_cputim:61,os_cputime_delay_nsec:86,os_cputime_delay_tick:86,os_cputime_delay_usec:86,os_cputime_freq:24,os_cputime_freq_pwr2:86,os_cputime_get32:86,os_cputime_init:86,os_cputime_nsecs_to_tick:86,os_cputime_ticks_to_nsec:86,os_cputime_ticks_to_usec:86,os_cputime_timer_init:86,os_cputime_timer_num:[24,86],os_cputime_timer_rel:86,os_cputime_timer_start:86,os_cputime_timer_stop:86,os_cputime_usecs_to_tick:86,os_dev:[61,134,206,207,208,276,280],os_dev_clos:[207,280],os_dev_cr:[134,206,207,208,211,276],os_dev_init_func_t:[134,208],os_dev_init_kernel:276,os_dev_init_primari:207,os_dev_init_prio_default:276,os_dev_open:[207,276,280],os_einv:[89,100,204],os_eno:129,os_error_t:[90,91,98],os_ev:[84,87,89,97,129,130,238,258,282],os_event_fn:[84,87,89],os_event_queu:87,os_event_t_mqueue_data:89,os_event_t_tim:84,os_eventq:[61,84,87,89,97,130,216,238,274,275,276],os_eventq_dflt_get:[26,87,92,99,130,225,238,254,255,258,280,282],os_eventq_dflt_set:275,os_eventq_get:[87,97],os_eventq_get_no_wait:87,os_eventq_init:[87,89,97,130,238,274,275],os_eventq_pol:87,os_eventq_put:[87,130,238],os_eventq_remov:87,os_eventq_run:[26,87,89,92,99,225,238,254,255,258,275,280,282],os_fault:61,os_get_uptime_usec:100,os_gettimeofdai:100,os_heap:61,os_init:[86,99],os_invalid_parm:[91,98],os_main_task_prio:[225,243],os_main_task_stack_s:225,os_malloc:[61,88],os_mbuf:[61,89,217,218],os_mbuf_adj:89,os_mbuf_append:[89,274,276],os_mbuf_appendfrom:89,os_mbuf_cmpf:89,os_mbuf_cmpm:89,os_mbuf_concat:89,os_mbuf_copydata:89,os_mbuf_copyinto:89,os_mbuf_count:89,os_mbuf_data:89,os_mbuf_dup:89,os_mbuf_extend:89,os_mbuf_f_:89,os_mbuf_f_mask:89,os_mbuf_fre:89,os_mbuf_free_chain:89,os_mbuf_get:89,os_mbuf_get_pkthdr:89,os_mbuf_is_pkthdr:89,os_mbuf_leadingspac:89,os_mbuf_off:89,os_mbuf_pkthdr:89,os_mbuf_pkthdr_to_mbuf:89,os_mbuf_pktlen:89,os_mbuf_pool:89,os_mbuf_pool_init:89,os_mbuf_prepend:89,os_mbuf_prepend_pullup:89,os_mbuf_pullup:89,os_mbuf_trailingspac:89,os_mbuf_trim_front:89,os_mbuf_usrhdr:89,os_mbuf_usrhdr_len:89,os_memblock:90,os_memblock_from:90,os_memblock_get:90,os_memblock_put:90,os_memblock_put_from_cb:90,os_membuf_t:[89,90],os_mempool:[61,89,90],os_mempool_byt:90,os_mempool_ext:90,os_mempool_ext_init:90,os_mempool_f_:90,os_mempool_f_ext:90,os_mempool_info:90,os_mempool_info_get_next:90,os_mempool_info_name_len:90,os_mempool_init:[89,90],os_mempool_is_san:90,os_mempool_put_fn:90,os_mempool_s:[89,90],os_mqueu:89,os_mqueue_get:89,os_mqueue_init:89,os_mqueue_put:89,os_msys_count:89,os_msys_get:89,os_msys_get_pkthdr:89,os_msys_num_fre:89,os_msys_regist:89,os_msys_reset:89,os_mutex:[61,91,140,206],os_mutex_init:91,os_mutex_pend:91,os_mutex_releas:91,os_ok:[91,98],os_pkg_init:225,os_san:[61,97],os_sanity_check:[97,99],os_sanity_check_func_t:97,os_sanity_check_init:97,os_sanity_check_regist:97,os_sanity_check_reset:97,os_sanity_check_setfunc:97,os_sanity_task_checkin:97,os_sch:61,os_sched_get_current_t:243,os_sched_get_current_task:[85,97,243],os_sem:[61,92,98,275],os_sem_get_count:98,os_sem_init:[92,98,275],os_sem_pend:[92,98,275],os_sem_releas:[92,98,275],os_sem_test_bas:230,os_sem_test_case_1:230,os_sem_test_case_2:230,os_sem_test_case_3:230,os_sem_test_case_4:230,os_sem_test_suit:230,os_settimeofdai:100,os_stack_align:[243,274,275,276],os_stack_t:[97,99,217,238,243,274,275,276],os_start:99,os_stime_t:100,os_sysview:[242,290],os_task:[61,85,87,91,92,97,99,238,243,274,275,276],os_task_count:99,os_task_flag_evq_wait:99,os_task_flag_mutex_wait:99,os_task_flag_no_timeout:99,os_task_flag_sem_wait:99,os_task_func_t:[97,99],os_task_info:99,os_task_info_get_next:99,os_task_init:[92,97,99,238,243,274,275],os_task_max_name_len:99,os_task_pri_highest:99,os_task_pri_lowest:99,os_task_readi:99,os_task_remov:99,os_task_sleep:99,os_task_st:99,os_task_state_t:99,os_test:61,os_test_restart:233,os_tick_idl:[189,256,259,282],os_tick_init:189,os_ticks_per_sec:[84,97,100,129,189,208,238,243,258,274,275,276,282],os_tim:[61,100,267],os_time_adv:100,os_time_delai:[99,100,208,238,240,243,274,276],os_time_get:100,os_time_max:100,os_time_ms_to_tick:100,os_time_t:[84,87,97,99,100,189,206,208],os_time_tick_geq:100,os_time_tick_gt:100,os_time_tick_lt:100,os_timeout:[91,98,275],os_timeout_nev:[92,100,207,280,282],os_timeradd:100,os_timersub:100,os_timev:[100,267],os_timezon:[100,267],os_wait_forev:[87,92,99,238,243,274,275],osmalloc:88,ostask:99,ostick:100,osx:[235,240],ota:236,otg1:262,otg2:[262,288],other:[1,6,10,11,20,22,24,29,31,50,55,61,86,87,89,90,92,93,94,97,98,99,100,128,129,130,134,152,153,161,164,169,173,174,176,179,184,187,205,208,210,214,222,223,225,235,238,241,242,243,246,247,248,249,251,252,256,257,258,259,265,267,269,274,276,277,278,279,282,284,289,290],otherwis:[89,90,92,99,142,144,147,186,190,269,270],oti:99,oti_cswcnt:99,oti_last_checkin:99,oti_nam:99,oti_next_checkin:99,oti_prio:99,oti_runtim:99,oti_st:99,oti_stks:99,oti_stkusag:99,oti_taskid:99,oui:[19,264],our:[20,55,89,93,222,223,235,236,240,243,246,249,254,255,257,258,267,270,274,275,276,285,288],our_id_addr:[30,250],our_id_addr_typ:250,our_key_dist:27,our_ota_addr:[30,250],our_ota_addr_typ:[30,250],out:[8,9,10,11,20,21,22,23,26,27,61,80,81,82,84,89,95,99,128,130,136,140,141,144,146,160,161,173,180,181,182,198,200,201,202,203,222,226,233,246,248,250,254,255,257,262,268,275,287],out_cpha:190,out_cpol:190,out_data:[162,163],out_dir:[161,162,164],out_fil:[160,162],out_id_addr_typ:30,out_len:[157,162,163,171],out_nam:[136,156,162],out_name_l:156,out_name_len:[156,162],out_off:89,out_tick:100,outdat:58,outfil:[1,34,35,37,38,39,40,41,42,43,44,45,46,47,48,49,50,51,52,53,54,57,58,59,62,275],outgo:218,outlin:5,output:[1,7,12,21,22,27,30,34,35,37,38,39,40,41,42,43,44,45,46,47,49,50,51,52,54,57,58,59,62,69,73,75,76,77,81,88,93,99,100,128,129,181,186,193,205,222,224,226,235,238,241,256,258,259,260,262,263,264,267,268,275,278,282,286,289],outsid:[20,21,89],outweigh:89,over:[20,21,22,23,27,29,31,65,66,67,68,69,70,71,72,73,74,75,76,77,89,128,133,134,136,140,142,150,187,193,205,222,236,241,243,251,257,258,260,264,268,274,275,277,278,279,281,284,287,289,292],overal:[10,24,89,99,173],overhead:89,overlap:[20,179],overrid:[50,61,64,65,66,67,68,69,70,71,72,73,74,75,76,77,80,81,82,93,205,222,223,236,247],overridden:[23,225,247],oversampl:276,overview:[128,278,279,282],overwrit:[6,49,50,59,60,82,83,93,130,179,256,265,268],overwrite_many_test:267,overwrite_one_test:267,overwrite_three_test:267,overwrite_two_test:267,overwritten:[128,172,179],own:[2,11,19,20,39,57,58,59,61,87,91,92,96,98,99,135,179,190,205,222,223,244,245,246,275,276],own_addr_t:[254,255],own_addr_typ:[27,66,254,255],owner:[87,91,271],ownership:[91,179,275,276],pacakg:246,pacif:100,pack:[4,55,81,89,239,259,261,268,278,282,285],packag:[6,9,11,23,24,26,34,39,40,41,43,45,50,51,52,53,55,56,58,59,60,79,83,87,92,94,99,128,129,131,132,134,137,138,152,162,173,181,182,195,196,199,207,208,211,212,213,214,222,223,230,231,232,235,238,247,257,258,259,264,266,269,270,276,279,280,281,292],package1:205,package1_log:205,package2:205,package2_log:205,packet:[20,21,27,29,187,214,218,254,264],packet_data:89,pacman:[7,59],pad:[89,128],page:[1,4,5,6,7,8,10,20,22,57,58,60,80,81,83,93,101,135,180,187,188,206,207,208,209,235,240,244,246,248,252,254,255,257,276],page_s:135,pair:[20,21,22,27,66,128,129,179,199,204,225,250,252],pakcag:214,panel:12,paradigm:89,param:[27,214,219,252],param_nam:214,paramet:[1,20,26,27,28,30,61,66,72,84,86,87,89,90,91,97,98,99,100,136,140,150,182,186,187,189,190,192,193,194,205,207,208,214,225,236,249,251,252,253,254,255,267],parameter_nam:225,parameter_valu:225,parent:[90,154,155,156,161,164,166,172,179],parenthes:89,pariti:193,parlanc:11,parmaet:27,parmet:[27,28],pars:[55,197,214,226,229,254,267],part:[22,29,89,95,128,140,168,173,174,179,180,222,249,250,253,275,276,281],parti:[254,256,268],partial:[64,65,66,67,68,69,70,71,72,73,74,75,76,77,80,81,82,89,128,173,174],particular:[4,20,47,61,89,92,93,96,97,128,130,134,152,181,190,192,199,233,252,254,255],particularli:265,partit:[20,93,128,173,179,222],pass:[1,7,12,20,27,61,84,86,87,89,90,91,97,98,99,130,134,135,139,140,150,160,163,171,179,186,187,190,192,193,199,206,207,208,210,214,217,227,228,229,230,249,253,254,255,267,276,282],passiv:27,passkei:[20,22,27],password:[11,58,80,247,271],past:[20,89,276],patch:[259,260,263],path:[2,4,6,10,11,12,29,50,57,58,59,60,61,66,80,81,82,83,93,94,152,159,160,161,162,166,169,171,172,225,269,275,276],pathloss:29,pattern:[27,93,243],payload:[89,132,133,187],pc6:288,pc7:288,pca100040:247,pca:[239,261,276],pcb:275,pci:[134,181],pcmcia:[134,181],pdata:187,pdf:[235,288],pdt:[100,267],pdu:[20,27],peek:243,peer:[10,22,28,66,190,239,251,253,254,255],peer_addr:[27,30,66,249],peer_addr_typ:[27,30,66,249],peer_id:66,peer_id_addr:250,peer_id_addr_typ:250,peer_nam:[66,239],peer_ota_addr:250,peer_ota_addr_typ:250,pem:[37,46],pencil:10,pend:[20,84,87,91,98,128,187,239],per:[11,19,89,91,128,129,173,182,186,190,193,223,243,267,270,275],perfom:128,perform:[3,4,5,9,11,12,20,22,25,27,36,57,58,59,64,80,81,82,89,90,92,93,97,99,101,128,130,135,151,152,166,179,187,192,211,222,225,235,239,251,256,258,259,264,270,274,275,276,277,278,279,282],perhap:269,period:[9,19,22,27,84,97,189,194,238,243],peripher:[9,20,21,24,26,29,30,93,96,134,181,182,187,190,223,239,245,246,249,252,253,254,274,275,276],perman:[71,128,179,222,239,249,252],permiss:[275,276],permit:[20,241,242,253,256,282,289,290],persist:[128,151],perspect:222,pertain:252,petteriaimonen:101,phdr:89,phone:[22,31],php:55,phy:[21,27],phy_opt:27,physic:[21,27,29,66,130,183,186,193],pick:[85,92,205,254,255],pictur:[235,259],pid:260,piec:[21,93,275],pig:244,pin:[7,8,20,93,96,99,134,181,183,186,187,190,191,193,206,235,238,258,259,262,264,268,275,276,278,282,288],ping:92,pinout:95,piqu:292,pitfal:89,pkcs15:128,pkg1:224,pkg2:224,pkg:[1,7,11,39,43,50,53,55,57,58,59,61,94,95,101,130,134,135,136,151,152,180,181,205,207,214,223,224,225,236,238,246,258,267,275,276,277,282],pkg_init_func1_nam:225,pkg_init_func1_stag:225,pkg_init_func2_nam:225,pkg_init_func2_stag:225,pkg_init_func:225,pkg_init_funcn_nam:225,pkg_init_funcn_stag:225,pkg_test:232,pkga_syscfg_nam:225,pkga_syscfg_name1:225,pkga_syscfg_name2:225,pkgn_syscfg_name1:225,pkt:275,pkthdr_len:89,pkts_rxd:89,place:[3,55,61,87,100,101,128,140,168,187,190,222,225,231,236,240,243,246,247,253,254,255,262,270,275,284],plai:[12,21,284],plain:[222,260,270],plan:[2,134,214],platform:[2,7,9,11,12,23,24,57,58,59,66,80,81,82,84,92,93,94,96,134,182,187,190,192,231,239,243,246,256,258,259,260,262,263,268,275,276,278,285,286,287,288],pleas:[10,39,57,58,59,94,95,206,210,211,223,235,240,241,242,256,257,269,276,282,289,290],plenti:[243,275],plist:61,plu:[89,156,179,187],plug:[8,180,235,262,263,275,276],plumb:274,pmode:278,point:[2,4,6,31,85,89,91,93,95,99,101,128,130,134,141,142,143,144,145,147,148,149,150,161,162,164,179,190,206,246,251,252,254,255,275,276,277],pointer:[67,84,85,86,87,89,90,91,93,98,99,100,130,134,140,141,142,150,153,155,156,157,158,160,162,163,168,170,171,172,179,180,182,187,190,192,197,198,199,205,206,207,208,211,214,215,216,219,220,226,243,251,252],poke:276,polici:[27,269],poll:[87,92,210,278,282],poll_du:278,poll_dur:278,poll_interv:278,poll_itvl:278,poller:[206,210,211,282],pong:92,pool:[73,80,92,264,279,286],popul:[1,7,12,50,62,100,175,179,231,257,268,284,287,292],port:[2,12,66,92,130,134,186,193,205,223,236,247,256,258,259,260,261,262,263,268,275,278,282,285,286,287,288,292],portabl:[134,181],portingto:94,portion:[128,146,187,274,276],posit:[89,100,128,158,168,171,194,262],posix:59,possibilti:[241,242,289,290],possibl:[21,22,24,27,28,30,32,36,53,89,91,100,128,134,152,173,174,179,181,182,205,222,223,241,253,269,278,289],post:[49,84,89,134,238,246],potenti:[96,222,270],pour:[58,81],power:[2,9,20,21,22,27,29,31,55,93,96,130,134,181,182,190,191,208,236,239,247,256,261,262,264,268,277,278,279,280,282,285,288],ppa:4,pre:[4,9,205,223,269,270],precaut:251,prece:89,preced:23,precis:[6,20],predict:243,preempt:[91,92,98,99],preemptiv:[92,99,243],prefer:[3,27,29,138,239,251,275],preference0x01:27,prefix:[61,179,209,225,276],preload:190,prepar:[20,259,261,264,276],prepend:89,preprocessor:[214,223],prerequisit:12,presenc:[93,179,249,254,255,269],present:[1,89,93,128,130,179,195,207,222,247,262,267,276],preserv:89,press:[8,12,98,238,242,243,246,268,275,278,290],presum:[89,264],pretti:276,prev:[99,179],prev_ind:252,prev_notifi:252,prevent:[91,92,128,169,251],previ:[250,252],preview:[244,247,261],previou:[21,56,57,58,59,78,79,80,81,82,99,128,179,199,224,225,246,247,258,269,274],previous:[6,12,57,58,59,60,80,81,82,83,190,236,250,272,276,278],prevn:[250,252],pri:[77,182,275,285,288],primari:[27,93,128,132,166,239,253,255,274],primarili:101,primary_phi:27,primo:[257,274,275],primo_boot:259,primo_debug:259,primoblinki:259,print:[48,57,58,59,62,129,130,136,154,155,156,161,164,171,193,214,224,226],print_statu:171,print_usag:197,printabl:198,printf:[101,136,226,229],prio:[97,99,189,217],prior:[22,24,49,89,92,128,166,175,179,190,192,264],prioriti:[77,85,87,91,92,98,99,134,173,182,189,225,238,247,276,292],priv:27,privaci:[19,21,27],privat:[19,22,32,37,46,57,66,80,128,254,255],privileg:2,pro:[243,256,259],probabl:[7,10,93,248,271,275],probe:[187,259,268,282],problem:[7,98,128,161,222,224],proce:[3,6,11,128,233,256,259,260,261,262,263,267,268,275,285,288],procedur:[6,11,16,19,20,22,27,28,64,75,80,81,82,128,179,180,222,278,281],proceed:[7,248,254,255],process:[3,6,9,10,20,22,26,27,31,61,84,85,87,89,93,99,128,130,131,179,211,212,216,222,223,225,235,236,238,241,242,243,254,255,277,280,281,282,289,290],process_data:169,process_rx_data_queu:89,processor:[4,9,89,99,134,181,182,186,241,242,243,256,262,282,289,290],produc:[98,128,223,229,260],product:[55,96,174,186,209,247,275,288],profil:[14,15,16,17,21,27,28,31,64,65,66,67,68,69,70,71,72,73,74,75,76,77,78,80,81,82,246,256,285,287,288],profile01:[65,67,68,69,70,71,72,73,74,75,76,77],profile0:77,program:[4,6,8,12,23,85,128,130,188,191,235,243,256,258,259,261,264,268,276],programat:130,programm:[241,242,260,289,290],programmat:[137,282],progress:[7,20,128,134,135,179,190,245],prohibit:167,project:[3,6,8,11,33,34,39,40,41,44,49,50,52,55,57,58,59,61,63,88,99,101,128,129,130,135,136,138,151,176,177,181,195,205,223,230,231,238,240,241,243,244,250,267,271,272,277,278,282,283,284,289,292],prompt:[7,8,11,12,47,58,59,93,246,256,258,259,260,261,262,263,275,278,282],prone:253,proper:[134,276],properli:[24,61,92,97,243,247,251,274,275,276],properti:[12,19,31,59,93,128,133,173,174,179,205,235,248,259],proport:179,propos:10,propper:275,prot_length:89,prot_tif:89,prot_typ:89,protcol:89,protect:[22,88,128,140],protocol:[14,20,21,28,61,66,89,128,132,133,187,279,281,284,287],prototyp:[96,193,225,254,255],provid:[1,2,7,9,11,12,19,20,21,22,27,30,31,37,39,45,50,57,58,59,66,70,71,72,75,80,84,86,88,89,90,91,92,93,95,96,97,99,100,128,130,134,135,136,140,151,152,173,181,186,187,190,192,197,206,209,211,212,214,223,231,234,236,248,254,255,256,264,267,268,269,270,275,276,281],provis:[21,32],provision:31,proxi:[21,31],pseln:276,pselp:276,pset:190,psm:27,psp:[256,260],pst:[68,100,267],pth:262,ptr:193,public_id:27,public_id_addr:30,public_target_address:29,publish:22,pull:[11,49,80,82,87,89,134,186,238,258,262],pulldown:186,pullup:[89,186],purpos:[4,22,50,55,93,97,128,181,186,205,208,210,222,223,243,251,264,276,282],push:[10,244],put:[1,2,7,43,61,80,82,87,89,90,91,93,98,99,100,133,182,243,249,254,255,267,276],putti:[8,258,268,278],pwd:[2,11],pwm:9,pwr:[260,262],px4:4,python:[33,63],qualifi:251,qualiti:283,quat:278,queri:[9,19,50,55,57,58,59,61,62,89,133,155,156,157,158,171,179,206,208,223,249,278,286],question:246,queu:[20,84,87,193,238],queue:[26,61,84,86,89,92,97,98,99,130,179,192,211,214,216,218,225,236,254,255,274,280,282,284,292],quick:[2,3],quickli:[100,181,243,276,278,281,282,284],quickstart:[2,243],quiet:[1,34,35,37,38,39,40,41,42,43,44,45,46,47,48,49,50,51,52,53,54,57,58,59,62,275],quit:[19,93,241,246,249,254,255,256,259,260,262,263,289],quot:66,r_find_n:211,r_lock:211,r_match_:211,r_regist:211,r_unlock:211,radio:[21,24,247],raff:81,rais:91,ram:[48,93,95,173,182,222,246,256,275,276,277],ram_siz:93,ran:97,rand:27,random:[19,20,25,27,30,66,247,253,254,255,274],random_id:27,random_id_addr:30,randomli:19,rang:[9,20,21,29,89,101,179,197,264],rare:89,rate:[66,84,130,211,212,247,264,278,281,282],rather:[14,20,93,100,101,128,152,166,222,276],raw:[11,57,58,59,80,81,82,130,173,179,225,226,276],rb_bletini:50,rb_blinki:[43,50],rb_blinky_rsa:43,rb_boot:43,rbnano2_blinki:263,rbnano2_boot:263,reach:[97,192],read:[4,6,7,11,12,14,18,19,20,23,27,28,55,61,64,65,68,73,76,77,80,81,82,87,89,99,128,129,130,134,135,136,140,142,145,146,150,152,153,154,155,156,158,160,161,163,164,168,169,171,179,184,186,187,192,199,204,205,210,211,212,213,225,226,235,236,238,239,241,242,243,250,252,253,254,255,256,257,260,263,264,267,268,269,274,275,276,277,278,279,281,284,287,289,290],read_acceleromet:282,read_cb:282,read_chr:251,read_config:[153,160,163],read_part1_middl:168,read_rsp_rx:76,read_rsp_tx:76,read_sensor_interv:282,read_test:267,read_type_req_rx:76,read_type_req_tx:[76,236],read_type_rsp_rx:[76,236],read_type_rsp_tx:[76,236],readabl:[247,271],readdesc:7,readdir_test:267,reader:[267,274,276],readi:[10,85,87,99,130,193,199,241,243,256,275,289],readili:134,readm:[7,11,55,61,93,246,267],readnow:61,real:[1,7,9,87,92,100,130,179,199,234,238,241,246,253,282,289],realist:267,realli:[89,276],rearm:84,rearrang:89,reason:[10,20,26,27,89,90,128,191,243,250,252,264,267,269],reassembl:21,rebas:11,reboot:[7,71,128,191,222,224,239,277,279],reboot_log:72,reboot_log_flash_area:[224,225],reboot_start:280,rebuild:[32,61,82,280],rec0:128,rec1:128,rec2:128,recal:[251,269],receiv:[10,14,20,27,29,31,55,81,89,130,131,136,187,190,193,206,211,214,217,220,236,249,252,253,260,264,282,285,288],recent:[179,259],recip:6,recipi:29,reclaim:179,recogn:[55,179,276],recommend:[3,4,7,12,57,58,80,81,89,130,188,207,208,214,224,225,236,238,241,249,253,259,263,265,278,284,289],reconfigur:[190,193,280],reconnect:251,record:[128,179,208,223,231,242,290],recov:128,recover:128,recreat:270,recur:194,recurs:[55,61,90,169],red:[27,28,235,260,262,288],redbear:[257,292],redefin:224,redistribut:[55,241,242,256,269,282,289,290],reduc:[9,22,24,31,87,101,132,205,236,238,266],redund:222,reenter:265,ref0:67,refer:[7,8,10,18,22,23,29,55,67,93,166,169,179,190,209,215,219,222,244,249,254,255,256,258,262,268,275,276,278,288],referenc:[1,179,186],reflect:250,reformat:179,refrain:26,refresh:[2,49,244,256],refus:[241,282,289],regard:[173,174,267,275,276],regardless:41,region:[89,93,128,167,173,174,179],regist:[23,75,85,89,94,129,131,134,138,152,162,165,181,182,187,196,205,206,210,212,215,217,219,220,221,225,243,251,253,275,276,282],register_:210,registr:[17,180,223,251,282],registri:[89,208],regress:[227,228,230,231,232],regular:[89,155,267],reject:[20,267],rel:[89,92,148],relai:[21,31],relat:[10,27,31,43,135,222,241,242,249,252,256,264,282,289,290],relationship:[27,98],releas:[3,4,7,31,49,56,78,79,89,90,91,92,98,134,186,187,214,225,256,268,269,270],release_not:[7,11],relev:[95,128,134,186],reli:[1,7,55,225],reliabl:[21,128,151,173,254,255,270],remain:[93,163,169,179,222,226,229,243,251],remaind:[93,179,229,249,267,269],rememb:[2,41,80,82,91,256,274],remind:256,remot:[1,7,9,12,20,27,28,49,55,66,78,80,81,82,132,187,235,236,238,239,247,256,257,258,268,275,276,282,284,286,287,292],remov:[2,4,6,27,35,45,60,83,86,87,89,90,98,99,130,136,179,222,251,256,282],renam:166,rename_test:267,repeat:[2,11,20,187,240,251],repeatedli:[29,128],replac:[4,6,93,95,101,195,222,225,226,229,240,256,258,274,285,288],repli:27,repo814721459:55,repo:[1,6,7,10,11,41,55,57,61,80,93,134,152,222,235,241,242,244,246,256,258,259,260,261,262,263,264,267,268,271,275,276,277,278,282,285,286,288,289,290],repop:7,report:[1,4,6,10,20,93,182,193,223,226,229,241,242,256,260,267,275,282,289,290],reposistori:7,reposit:168,repositori:[1,4,11,12,40,41,44,49,51,52,57,61,80,134,235,244,245,246,248,256,257,264,268,272,275,284,287,292],repres:[1,12,61,87,89,98,100,128,130,159,179,206,208,210,211,214,243,253],represent:[128,132],reproduc:[1,61,128,180,254,255],req_api:[61,130,205],req_len:89,request:[12,20,27,66,67,74,78,89,91,93,98,128,132,133,136,140,163,179,191,209,210,212,214,222,236,250,251,256,260,262,264,269,270,274,276,277,281,282,285,288],requir:[1,2,4,6,9,11,20,24,30,31,53,59,61,66,80,82,87,89,90,92,94,95,96,98,128,130,132,135,152,162,173,174,179,192,205,207,214,222,223,224,225,228,235,236,238,243,246,249,251,256,259,263,264,267,269,270,274,275,276,278,280,281,282,292],res:277,reserv:[20,89,93,96,141,143,179,206,243,264],reserved16:179,reserved8:179,reset:[25,64,78,80,81,82,84,97,131,132,191,222,233,236,241,242,246,247,250,259,260,261,263,276,278,282,289,290],reset_cb:26,reset_config:256,reset_handl:[93,262],resid:[96,128,174,179,240,253,275],resign:[57,58,59],resist:276,resistor:[238,276],resolut:[22,86,192,223,276],resolv:[1,19,20,22,27,32,55,66,81,224,235,254,255,269],resourc:[9,20,29,61,88,91,98,133,209,210,212,214,235,238,241,242,256,277,279,281,282,288,289,290],respect:100,respond:[17,25,222,249,251,253,274,275],respons:[10,15,20,28,29,69,85,90,92,130,132,136,212,222,243,249,251,268,275,281,285,286,288],rest:[1,46,61,89,179,197,199,226],restart:[2,128,129,140,179,191,256],restor:[129,173,176,177,179,259,261,264,276],restrict:[128,140,173,174,179,214,225,251,252],restructuredtext:10,result:[10,12,20,58,62,89,100,160,161,174,179,198,206,223,225,229,231,253,260,267,274,275,276],resum:[21,99,128,179,249,252],resynchron:49,retain:[128,179,225,252],retent:182,retransmit:31,retreiv:133,retri:[263,264],retriev:[57,80,87,89,100,132,152,154,155,156,157,158,161,163,164,171,174,206,208,246,284],reus:[55,81,128,225],reusabl:55,rev:278,revdep:[1,50,62],revers:[1,23,50,62,128,179,251,262],revert:[128,239],review:[10,222,249,267],revis:[4,197,278],revision_num:[269,270],revisit:[246,252],rewrit:179,rewritten:179,rfc:[68,199,267],ribbon:[262,288],rigado:[48,261,276],right:[2,3,10,55,61,129,244,249,262,276],rimari:253,ring:98,rise:186,ristic:253,rite_fil:152,robust:151,role:[20,21,30,31,98,251],room:[89,179,243],root:[2,4,8,31,80,136,165,179,235,269],rotat:166,rotate_log:166,routin:[101,129,140,141,143,162,180,199,230,275],rpa:[19,27],rpa_pub:[27,66],rpa_rnd:[27,66],rsa2048:128,rsa:128,rsp:27,rssi:[27,29,247],rtc:9,rto:[55,92,243],rtt:[130,291,292],rtt_buffer_size_down:[241,289],rubi:[11,55,58],rule:[225,260,267],run:[2,3,4,5,6,8,9,11,23,24,30,34,39,41,43,50,52,55,57,58,59,60,61,64,66,67,77,78,80,81,82,83,84,85,86,87,89,91,92,93,96,97,98,99,128,129,131,132,135,136,152,160,161,179,192,212,214,220,222,224,232,233,234,235,236,239,240,243,246,247,254,255,257,259,260,261,262,263,264,267,268,275,276,277,278,279,280,282,285,287,288,292],runner:12,runtest:[7,131,236],runtest_newtmgr:236,runtim:[25,77,99,256,268,275,285,288],runtimeco:[57,58,59,80,81,82,235,256,268,269,276],rwx:93,rwxr:[80,82],rx_cb:130,rx_data:275,rx_func:193,rx_off:275,rx_phys_mask:27,rx_power:27,rxbuf:190,rxpkt:89,rxpkt_q:89,s_cnt:223,s_dev:206,s_func:206,s_hdr:223,s_itf:206,s_listener_list:206,s_lock:206,s_map:223,s_map_cnt:223,s_mask:206,s_name:223,s_next:[206,223],s_next_run:206,s_pad1:223,s_poll_rat:206,s_size:223,s_st:[206,282],s_type:206,saadc_config_irq_prior:276,saadc_config_oversampl:276,saadc_config_resolut:276,sad:282,sad_i:282,sad_x:282,sad_x_is_valid:282,sad_y_is_valid:282,sad_z:282,sad_z_is_valid:282,safe:[90,152],safeguard:92,safeti:251,sai:[61,89,99,256,268,269,270,275],said:[186,276],sam0:256,sam3u128:[259,261,264,276,282],samd21:[256,268],samd21g18a:256,samd21xx:256,samd:256,same:[6,10,12,22,29,34,37,47,51,59,61,78,89,91,93,94,98,128,130,151,173,179,187,211,222,223,224,225,226,235,238,240,243,249,251,252,257,259,261,264,269,270,271,276,277],sampl:[1,12,21,30,61,89,94,134,212,222,225,276,277,279,281,282,287],sample_buffer1:276,sample_buffer2:276,sample_cmd:221,sample_cmd_handl:221,sample_command:219,sample_modul:[219,221],sample_module_command:219,sample_module_init:219,sample_mpool:219,sample_mpool_help:219,sample_mpool_param:219,sample_target:53,sample_tasks_help:219,sample_tasks_param:219,sane:99,saniti:[77,92,99,246],sanity_interv:97,sanity_itvl:[97,99],sanity_task:97,sanity_task_interv:97,satisfactori:269,satisfi:[179,270],sattempt_stat:223,save:[12,31,49,50,71,100,129,130,187,208,243,251],saw:252,sbrk:[93,259,260,261,262,263],sc_arg:97,sc_checkin_itvl:97,sc_checkin_last:97,sc_cmd:[214,215,219,220,221,275],sc_cmd_f:214,sc_cmd_func:[214,215,219,220,221,275],sc_cmd_func_t:214,sc_func:97,sc_next:152,sc_valtyp:206,scalabl:[151,179],scale:31,scan:[15,21,24,26,27,29,179,247,249,277,279],scan_interv:27,scan_req:27,scan_req_notif:27,scan_result:268,scan_rsp:27,scan_window:27,scannabl:[27,30],scenario:[22,98,195],scene:31,schedul:[9,24,84,87,92,96,99,100,243],schemat:[93,288],scheme:[19,29,93],scientif:21,sck_pin:[135,136],scl:[187,278],sco:20,scope:[12,89,243],scratch:[93,128,140,141,143,222],screen:[8,264],script:[7,42,61,137,139,262],scroll:[12,236,250],sd_get_config:[206,208],sd_read:[206,208],sda:[187,278],sdcard:136,sdk:[45,53,225],search:[12,87,94,134,176,179,211,241,242,246,256,262,269,277,282,289,290],searchabl:134,sec000:128,sec125:128,sec126:128,sec127:128,sec:[278,282],second:[22,26,27,61,64,65,66,67,68,69,70,71,72,73,74,75,76,77,80,81,82,84,89,90,93,97,99,100,128,140,194,214,222,235,240,243,249,254,255,258,262,267,274,275,276,278,282],secondar:253,secondari:[27,71,93,128,239,253,275],secondary_phi:27,secret:[22,27],section:[1,5,6,7,11,12,14,24,25,29,30,61,89,92,93,99,128,179,208,222,224,225,236,239,243,245,249,252,253,256,257,268,269,270,276,284,286,287],sector:[128,140,141,146,148,149,150,179,184,262],sector_address:[135,184],secur:[21,128,222,253,271,274],see:[2,4,5,6,7,8,10,11,12,21,22,23,24,33,36,43,55,57,58,59,61,63,64,66,80,81,82,87,89,91,92,93,96,99,128,137,147,160,181,187,190,199,205,206,207,208,209,210,211,212,213,214,223,224,225,235,236,239,240,241,242,243,244,246,247,249,250,251,253,254,255,256,257,258,259,260,261,262,263,264,265,268,269,270,271,274,275,276,277,278,279,281,282,284,285,287,288,289,290],seek:[89,168,179],seem:[249,276],seen:[90,185,188,269,292],segger:[130,239,259,261,264,268,276,278,282,285,291,292],segger_rtt_conf:[241,289],segment:[21,89,277],sel:288,select:[4,12,19,21,55,59,179,186,190,206,214,242,256,258,259,260,262,277,279,288,290],selector:206,self:[3,30,94,254,255,267],selftest:267,sem:98,sem_token:98,sema:275,semant:252,semaphor:[92,99,275],semi:275,send:[3,10,14,20,27,28,31,38,42,47,64,66,67,69,74,78,80,81,82,89,130,132,133,187,190,193,212,234,235,240,249,257,274,276,281,286,292],send_pkt:89,sender:249,sens:[20,128,222,276],senseair:[274,275],senseair_cmd:275,senseair_co2:[274,275],senseair_init:275,senseair_read:[274,275],senseair_read_typ:[274,275],senseair_rx_char:275,senseair_shell_func:275,senseair_tx:275,senseair_tx_char:275,sensi:277,sensibl:225,sensor:[9,31,134,223,292],sensor_accel_data:282,sensor_callout:282,sensor_cfg:[206,208],sensor_cli:[213,278,279,282],sensor_cr:[207,278,280],sensor_data_func_t:[208,210],sensor_data_funct_t:208,sensor_dev_cr:207,sensor_devic:206,sensor_driv:[206,208],sensor_ftostr:282,sensor_g:206,sensor_get_config_func_t:[206,208],sensor_get_itf:208,sensor_in:206,sensor_init:[206,208],sensor_itf:[206,207,208],sensor_itf_i2c:[206,207],sensor_itf_spi:206,sensor_itf_uart:206,sensor_listen:[206,210,282],sensor_lo:206,sensor_mg:211,sensor_mgr_find_next_bydevnam:[211,282],sensor_mgr_find_next_bytyp:211,sensor_mgr_l:211,sensor_mgr_lock:211,sensor_mgr_match_bytyp:211,sensor_mgr_regist:[206,208,211],sensor_mgr_unlock:211,sensor_mgr_wakeup_r:[211,282],sensor_nam:278,sensor_o:[212,277,278,279,281,282],sensor_offset:278,sensor_oic_init:[212,277],sensor_oic_obs_r:[212,281],sensor_r:[206,210],sensor_read:[206,210],sensor_read_func_t:[206,208],sensor_register_listen:[210,282],sensor_s:206,sensor_set_driv:[206,208],sensor_set_interfac:[206,208],sensor_set_poll_rate_m:[206,211,282],sensor_set_type_mask:[206,208],sensor_shel:278,sensor_timestamp:206,sensor_type_acceleromet:[206,207,208,280,282],sensor_type_al:206,sensor_type_eul:[208,280],sensor_type_grav:[208,280],sensor_type_gyroscop:[206,208,280],sensor_type_light:206,sensor_type_linear_accel:[208,280],sensor_type_magnetic_field:[206,208,280],sensor_type_non:206,sensor_type_rotation_vector:[208,280],sensor_type_t:[206,208,210,211,282],sensor_type_temperatur:[206,208],sensor_type_user_defined_6:206,sensor_un:[206,210],sensor_unregister_listen:[210,282],sensor_value_type_float:[206,208],sensor_value_type_float_triplet:[206,208],sensor_value_type_int32:206,sensor_value_type_int32_triplet:206,sensor_value_type_opaqu:206,sensor_value_type_temperatur:208,sensornam:[206,207,208,209,278,280,282],sensorname_cli:208,sensorname_ofb:278,sensors_o:279,sensors_test:[277,278,280,281],sensors_test_config_bno055:280,sent:[20,29,130,179,187,190,193,214,251,253,264],sentenc:[62,244],sep:[4,81,82],separ:[20,26,34,35,50,51,66,128,134,176,179,197,205,222,223,251,254,255,256,259,260,262,263,264],seper:[241,289],sequenc:[92,128,130,173,179,226,229],sequenti:[173,174,179],seri:[128,159,191,253,292],serial:[10,66,87,128,129,130,132,133,134,140,182,187,190,223,236,238,239,259,263,264,275,277,278,279,286,287],serror_stat:223,serv:[18,55,93,140,209,222,277],server:[12,14,18,20,21,27,31,133,209,210,212,222,244,253,264,274,277,279,281,282],servic:[16,17,21,27,28,29,31,92,96,134,181,234,249,250,251,252,268,270,275,277],service_data_uuid128:[27,29],service_data_uuid16:29,service_data_uuid32:[27,29],sesnor:282,session:[12,38,39,47,55,57,58,59,61,93,241,256,259,260,262,263,289],set:[1,2,7,8,9,10,12,19,20,23,24,27,28,29,31,32,34,36,37,39,50,53,55,56,58,59,61,62,64,65,66,67,68,69,70,71,72,73,74,75,76,77,79,81,82,84,86,89,96,97,98,99,100,128,129,130,134,135,145,152,153,157,160,162,163,167,170,173,175,176,177,179,181,186,187,189,190,192,193,194,199,207,209,211,212,213,214,215,219,220,221,222,223,231,235,238,239,241,243,247,250,251,254,255,256,257,259,260,261,262,263,264,265,267,268,269,270,271,274,276,278,279,281,282,284,285,287,288,289],setting1:224,setting2:224,settl:25,setup:[11,57,59,60,71,80,82,83,208,222,236,239,246,247,257,258,274,275,276,278,282,284,285,286,287,288],sever:[3,20,21,23,27,61,93,94,96,100,128,179,222,225,233,234,253,254,255,261,262,269],sha256:128,sha:128,shall:[24,27,29],share:[4,22,88,89,91,92,98,222,238,269],sheet:208,shell:[1,7,8,21,30,55,59,80,96,129,130,137,138,205,209,215,216,217,218,219,220,221,223,224,225,235,236,241,243,257,264,265,274,275,277,278,279,284,289],shell_cmd:[214,215,219,220,221,275],shell_cmd_argc_max:[214,264],shell_cmd_func_t:214,shell_cmd_h:214,shell_cmd_help:[214,219,265],shell_cmd_regist:[214,220,275],shell_compat:214,shell_complet:214,shell_evq:275,shell_init:225,shell_max_compat_command:[214,215],shell_max_input_len:138,shell_max_modul:[214,219],shell_modul:214,shell_newtmgr:[214,236],shell_nlip_input_func_t:217,shell_nlip_input_regist:214,shell_os_modul:[214,265],shell_param:[214,219],shell_prompt_modul:[214,258],shell_regist:[214,221],shell_sample_mpool_display_cmd:219,shell_sample_tasks_display_cmd:219,shell_stack:[138,275],shell_stack_s:275,shell_task:[214,224,225,236,258,265,275,278,282],shell_task_handl:275,shell_task_init:138,shell_task_prio:[138,275],shell_task_prior:224,shell_task_stack_s:138,shield:92,shift:[12,21],ship:[6,10],shortcut:[12,275],shorten:249,shorter:[179,240],shorthand:[89,269],shortli:276,shot:264,should:[4,8,10,12,19,26,30,32,55,57,59,61,81,84,85,86,87,89,90,93,96,97,98,99,128,130,134,137,138,140,146,150,152,156,157,160,170,173,179,181,182,187,190,192,193,194,197,199,208,211,214,223,225,229,231,235,240,241,242,243,247,249,250,251,252,254,255,256,258,259,260,261,262,263,264,267,268,269,272,275,276,277,278,280,282,285,288,289,290],show:[1,4,5,6,7,8,11,12,27,28,31,36,39,40,43,50,53,57,58,59,60,61,62,72,80,81,82,83,89,99,129,130,193,205,219,222,224,225,231,234,235,236,238,239,241,242,243,244,247,253,256,257,258,259,260,261,262,263,264,268,274,275,276,277,278,279,280,281,282,284,285,286,288,289,290,292],shown:[6,7,12,43,55,61,89,92,128,135,192,208,223,235,251,256,259,261,264,267,269,271,274,276,278,280,282,286],si_addr:[206,207],si_cs_pin:206,si_num:[206,207],si_typ:[206,207],sibl:[11,270],sid:27,side:[12,21,30,129,275],sierra:[58,81],sig:[20,29,31],sign:[6,10,37,46,47,57,58,59,80,206,240,247,257],signal:[20,21,26,29,99,190,252],signatuar:12,signatur:[27,46,128],signed_imag:128,signifi:187,signific:[19,89,190,222,264],significantli:31,signigic:89,silent:[1,34,35,37,38,39,40,41,42,43,44,45,46,47,48,49,50,51,52,53,54,57,58,59,62,225,275],silicon:32,sim1:[285,286,288],sim:[6,7,61,94,275,285,287,288],sim_slinki:[224,286],similar:[1,8,10,12,92,93,207,247,264,267,274],similarli:[89,205],simpl:[12,20,21,61,85,89,92,93,98,99,101,129,132,134,151,181,223,235,243,248,249,254,255,258,276,282,284],simplehttpserv:[33,63],simpler:[93,253],simplest:[89,285,288],simpli:[6,10,87,89,90,98,99,130,181,222,235,243,245,250,256,274],simplic:[128,254,255],simplifi:[20,87,90,187],simul:[2,3,5,6,50,233,243,282,286],simultaen:89,simultan:[27,29,30],simultaneosli:152,sinc:[3,20,24,32,61,89,92,93,98,100,128,190,214,223,239,240,243,246,247,254,255,256,258,268,269,274,275,276,277],singl:[2,3,7,22,39,47,55,57,58,59,87,89,98,99,128,134,152,171,173,174,179,208,223,225,248,249,253,254,267,269],singli:179,sissu:191,sit:[14,18,134,181,222],site:[248,259,263],situat:[92,222],six:[22,23],size:[9,20,27,29,39,55,57,58,59,61,73,77,87,89,90,93,99,100,101,128,130,132,135,156,173,174,175,179,190,204,205,222,223,224,225,226,234,236,243,256,260,262,264,266,279],size_t:[156,162,199],sizeof:[89,129,136,153,154,155,156,160,161,163,164,171,204,207,226,243,249,251,252,255,274,275,276],skelet:247,skeleton:[7,44,50,235,246,247,256,259,260,261,262,263,264,268,276,285,286,288],skip:[6,11,47,59,128,140,142,256,259,260,261,262,263,268,285,288],sl_arg:[210,282],sl_func:[210,282],sl_next:210,sl_sensor_typ:[210,282],slash:179,slave:[27,29,187,190],slave_interval_rang:29,sleep:[9,85,87,89,91,98,99,100,182,238,243,258],slightli:[96,222],slink:[285,286,288],slinki:[7,45,61,130,152,176,177,222,224,225],slinky_o:[7,61],slinky_sim:224,slinky_task_prior:224,slist_entri:[152,179,206,210],slist_head:[91,206],slot0:128,slot1:128,slot:[7,20,61,71,195,222,239,241,242,247,250,256,258,259,260,261,262,263,264,265,268,275,278,282,285,288,289,290],slower:[3,96,97],small:[20,24,89,130,134,171,222,223,253,260,267,275,276],smaller:[10,89,132,194,222,244,256],smallest:[89,179],smart:[21,31,55,61,275,281],smarter:270,smp:[20,21],snapshot:[43,259,263,270],snip:[1,36,43,55,61,236,246,247,276],snippet:251,soc:96,socket:2,soft:[64,80,81,82,191],softwar:[1,3,4,6,21,38,42,47,50,96,97,128,181,234,239,241,256,259,261,262,268,269,275,276,278,282,285,289],solder:275,solut:[55,181,254,255],solv:[128,222],some:[1,8,12,30,64,76,89,90,92,93,96,98,99,101,128,130,136,140,151,152,153,160,163,173,174,182,190,193,205,219,224,231,235,236,241,242,243,248,249,250,251,252,254,255,258,259,260,263,264,265,267,268,269,275,276,282,285,288,289,290,292],somebodi:[129,275],somehow:61,someon:[10,85,276],someth:[20,235,241,246,247,268,271,289],sometim:[129,241,256,268,289],somewhat:[92,128,179],somewher:[128,179,222,276],soon:[21,270,276],sooner:194,sophist:243,sort:[179,250],sourc:[1,4,9,21,24,50,56,58,60,61,79,81,83,89,96,128,129,134,166,179,208,209,225,231,238,248,256,259,260,262,268,269,270,276,282,284,288],space:[12,21,34,35,50,51,66,89,96,140,141,156,173,174,187,195,198,214,222,223,246,254,257,268,284,287,292],spec:20,specfi:278,special:[8,89,96,135,222,226,229,253,254,255,267,268,269,270,275,278],specif:[11,20,21,22,23,29,31,57,58,59,61,62,85,87,89,90,92,93,95,96,100,128,132,134,150,152,173,174,181,186,187,189,190,191,192,193,195,205,206,208,222,225,226,230,231,236,243,247,249,251,252,254,255,256,262,264,267,268,269,275,276,285,288],specifi:[1,4,6,7,10,11,12,20,27,30,34,35,37,39,41,43,45,46,50,51,53,55,57,58,59,61,65,66,67,68,69,70,71,72,73,74,75,76,77,84,86,87,89,90,93,96,97,99,100,101,130,132,133,150,152,153,154,155,156,157,158,159,160,161,163,164,166,167,168,169,170,171,172,174,176,177,179,182,186,187,205,206,207,208,209,210,211,212,213,214,215,216,219,224,226,229,231,236,239,241,246,249,251,252,253,254,255,256,261,262,265,268,269,270,271,276,278,281,282,285,288,289],spectrum:21,speed:[9,21,179,193,241,256,259,260,261,264,276,289],spew:268,sphinx:[33,63],spi:[8,21,96,134,135,136,186],spi_cfg:[135,136],spi_miso_pin:[135,136],spi_mosi_pin:[135,136],spi_num:[135,136,190],spi_sck_pin:[135,136],spi_ss_pin:[135,136],spi_typ:190,spitest:[7,61],split:[7,71,93,179,191,224,239,276,285,286,288],split_app:7,split_app_init:225,split_config:[285,286],split_elf_nam:61,split_file_test:267,split_load:225,splitti:[7,61,222,224],spot:93,spread:21,spuriou:267,squar:187,sram:262,src:[6,7,11,45,50,55,61,70,80,82,89,93,95,134,176,177,180,181,184,188,189,191,197,225,231,240,243,246,256,259,260,261,262,263,264,267,268,274,275,276,278,280,282,285,286,288],src_off:89,ss_op_wr:251,ss_pin:[135,136],ssec:27,sstatic:274,st_cputim:282,st_ostv:282,stabil:[269,270],stabl:[1,7,57,58,80,81,269,270],stack:[1,9,18,21,24,26,27,30,55,77,85,87,89,92,99,222,225,245,246,247,248,249,251,252,253,264,275],stack_bottom:99,stack_len:217,stack_ptr:217,stack_siz:[97,99],staff:[80,81],stage:[97,128,134,207,222,225],stai:[160,161],stailq_entri:223,stale:[2,256],stand:[89,232],standalon:[10,222],standard:[7,21,31,100,132,133,134,135,151,152,160,181,249,254,255,264,274,275],standbi:[21,195],start:[2,4,8,9,10,12,26,27,28,30,38,47,59,62,71,82,86,88,89,90,91,92,93,95,99,128,134,137,140,141,143,146,152,159,160,168,171,174,179,187,188,190,191,192,193,194,203,211,222,225,233,235,242,243,244,245,246,249,256,257,258,259,260,262,263,264,267,269,274,275,276,277,278,279,280,282,286,290,292],starter:240,startup:[19,21,26,30,128,222,225,243,254,255],startup_stm32f40x:[260,262],stash:49,stat:[1,7,64,78,80,81,82,131,132,225,236,241,246,264,265,275,276,282,289],state:[6,21,26,31,52,55,85,87,93,97,99,100,133,140,176,177,181,182,186,199,238,239,243,256,262,270,272],statement:[11,225,236],statist:[1,48,64,73,76,77,80,81,82,241,264,285,286,288,289],stats_cli:[1,265,275],stats_hdr:[208,223],stats_inc:223,stats_incn:223,stats_init:[208,223],stats_init_and_reg:223,stats_module_init:225,stats_my_stat_sect:223,stats_nam:[1,37,38,76,208,223],stats_name_end:[208,223],stats_name_init_parm:[208,223],stats_name_map:223,stats_name_start:[208,223],stats_newtmgr:[1,224,225,236],stats_regist:[208,223],stats_sect_decl:[208,223],stats_sect_end:[208,223],stats_sect_entri:[208,223],stats_sect_start:[208,223],stats_size_16:223,stats_size_32:[208,223],stats_size_64:223,stats_size_init_parm:[208,223],statu:[10,11,20,136,171,222,239,250,252,254,256,264,275,285,286,288],stdarg:[226,229],stderr:197,stdio:276,stener:210,step:[2,4,6,7,12,47,55,57,59,80,82,92,93,94,128,130,187,207,222,223,244,246,247,254,255,256,259,260,261,262,263,264,268,269,275,276,285,286,288],sterli:270,sterlinghugh:270,stic:[251,253],still:[5,59,66,86,96,97,241,250,284,289],stitch:1,stksz:[77,275,285,288],stkuse:[77,275,285,288],stlink:260,stm32:[260,262,288],stm32_boot:288,stm32_slinki:288,stm32f2x:260,stm32f303vc:[235,240],stm32f3discoveri:235,stm32f4:[134,135,136,257],stm32f4_adc_dev_init:134,stm32f4_hal_spi_cfg:[135,136],stm32f4disc_blinki:260,stm32f4disc_boot:260,stm32f4discoveri:[53,260],stm32f4discovery_debug:260,stm32f4x:260,stm32f4xx:186,stm32f4xxi:186,stm32serial:288,stm32x:260,stm34f4xx:186,stm:288,stmf303:235,stmf32f4xx:186,stmf3:235,stmf3_blinki:[235,240],stmf3_boot:[235,240],stop:[2,27,84,86,140,150,187,188,192,193,249,268,278],stopbit:193,storag:[20,129,140,167,247,269],store:[1,11,22,27,31,34,35,37,50,55,57,59,61,80,85,87,89,100,129,130,140,147,179,190,195,198,199,217,223,246,249,251,252,269,275,276,277,282,284],stori:89,str:[130,193,199],straight:[249,275],straightforward:[246,276],strategi:243,strcmp:[129,275],stream:[21,199,204,205,217],strength:29,strict:[251,256],strictli:[173,174,179,276],string:[1,10,27,29,34,35,37,38,39,40,41,42,43,44,45,46,47,48,49,50,51,52,53,54,57,58,59,62,64,65,66,67,68,69,70,71,72,73,74,75,76,77,80,81,82,101,129,130,133,139,160,171,197,198,199,204,214,215,219,223,225,226,229,254,255,267,269,270,274,275,276,286],strip:[46,89],strlen:[249,251],strongli:152,struct:[84,85,86,87,89,90,91,92,93,97,98,99,100,128,129,130,134,135,136,140,141,142,143,144,145,146,147,148,149,150,153,154,155,156,157,158,160,161,163,164,165,166,168,169,170,173,176,177,179,180,182,185,187,190,192,197,198,199,200,201,202,203,204,205,206,207,208,210,211,214,215,216,217,218,219,220,221,223,226,231,232,238,243,249,251,252,253,254,255,258,267,274,275,276,280,282],structur:[7,11,12,18,28,55,61,78,84,87,89,90,91,92,93,98,99,128,130,134,136,146,162,175,178,187,192,197,198,205,207,208,209,215,219,220,223,251,257,267,268,275,276,280,284,287,292],strutur:89,stub:[61,101,205,238,254,255,258,267,275,276],studio:[5,13],stuff:269,style:[130,244],sub:[28,43,45,50,70,71,72,75,76,134,155,255,272],subcmd1:220,subcmd2:220,subcommand:[45,50,62,64,66,70,71,72,75,76,220],subcompon:21,subdirectori:[2,231,267],subfold:259,subject:179,submit:11,subrang:20,subscrib:[28,250,252,276],subsequ:[21,22,128,160,161,222,249,252,267],subset:[22,176,206,208,211,278],substitut:[6,244,246,247],subsystem:[30,59,87,129,130,135,136,214],subtract:[98,100],subtre:129,succe:[176,267],succesfulli:[239,240,241,242,246,247,250,256,258,259,260,261,262,263,264,268,275,278,282,285,288,289,290],success:[3,20,55,84,86,89,92,97,99,100,136,141,142,143,144,145,146,148,149,150,152,153,154,156,157,159,160,161,163,164,165,166,167,168,169,170,171,172,176,177,178,179,182,186,187,190,192,193,194,197,200,201,202,203,204,215,217,218,219,229,232,233,235,240,251,253,262,264,267,276],successfuli:[93,267,282],successfulli:[7,20,55,90,93,97,222,235,236,239,240,246,247,250,252,254,255,256,259,260,261,262,263,264,268,275,276,277,278,279,282,285,286,288],sudo:[4,6,7,11,57,58,60,80,83,247],suffici:[89,90,179],suffix:267,suggest:[3,6,211,234,265,292],suit:[6,55,228,230,231,246,266],suitabl:[20,93,173],summar:[93,222],summari:[6,11,19,36,214,219,255],supersed:179,supervision_timeout:[30,250],supplement:[29,249],supplementari:93,suppli:[152,170,172,176,191,267],support:[1,3,4,6,7,10,12,14,19,20,21,22,29,30,32,53,58,66,81,86,92,93,95,101,128,130,132,133,134,135,136,151,179,182,186,190,199,205,206,207,208,211,214,215,219,220,222,223,225,238,239,246,247,248,249,253,254,256,257,259,268,269,270,275,279,284,286,287,292],suppos:[43,91,98,186,223],suppress:286,suppresstasknam:12,sure:[2,7,8,57,89,198,246,247,249,251,256,258,264,267,269,274,275,276],suspend:278,svc:253,sw_rev:278,swap:[2,85,93,173,180,222,241,256,289],swclk:256,swd:[256,259,260,261,262,263,264,268,276,282],swdio:256,sweep:179,swim:260,swo:[259,268,282],symbol:[4,7,12,61,222,241,242,256,260,282,289,290],symlink:[60,83],sync:[20,25,39,57,58,59],sync_cb:[26,254,255],synchron:[20,39,49,57,58,59,96,98,134,190],syntax:[225,244,264,265,278],synthes:24,sys:[1,7,55,57,61,129,130,131,180,205,214,223,224,225,232,236,238,242,246,258,267,268,275,276,278,282,290],sys_config:[129,222],sys_config_test:7,sys_console_ful:222,sys_einv:[208,282],sys_enodev:208,sys_flash_map:[260,262],sys_log:222,sys_mfg:[7,256,259,260,261,262,278,285,288],sys_shel:222,sys_stat:222,sys_sysinit:[7,256,259,260,261,262,263,278,285,288],syscfg:[23,24,32,37,38,50,61,93,97,129,130,152,173,207,208,209,211,212,213,214,215,219,223,224,236,239,241,242,247,256,258,259,264,265,267,268,275,276,278,279,281,282,289,290],sysconfig:236,sysflash:[256,262],sysinit:[7,25,26,92,99,130,196,207,225,238,254,255,256,258,264,267,268,275,276,282],sysinit_assert_act:225,sysinit_panic_assert:[207,208,225],sysresetreq:256,system:[1,3,6,8,9,25,39,50,57,58,59,61,62,86,89,90,93,96,97,99,100,101,128,129,130,131,140,154,155,156,160,161,162,164,165,167,173,175,176,177,179,182,186,190,193,195,196,205,219,222,223,233,234,242,243,246,247,256,258,259,262,264,265,268,269,270,275,282,290],system_l:186,system_stm32f4xx:[260,262],systemview:292,sysview:[242,290,291],sysview_mynewt:[242,290],sytem:188,syuu:59,t_arg:99,t_ctx_sw_cnt:99,t_dev:206,t_driver:206,t_flag:99,t_func:[99,243],t_interfa:206,t_itf:206,t_name:99,t_next_wakeup:99,t_obj:99,t_poll_r:206,t_prio:[85,99],t_run_tim:99,t_sanity_check:99,t_stackptr:99,t_stacksiz:99,t_stacktop:99,t_string:204,t_taskid:99,t_type_m:206,t_uinteg:204,tab:[30,36],tabl:[19,20,93,128,131,151,160,179,225,251,253,264,278],tag:270,tail:[89,179],tailq_entri:[179,192],tailq_head:179,take:[6,7,23,45,50,55,62,89,92,129,141,198,211,222,223,243,249,251,252,253,254,255,267,274,276],taken:[7,61,87,92,251,269,270,274],talk:[247,249,286],tap:[4,56,79],tar:[4,57,58,59,60,81,82,83],tarbal:4,target:[3,4,5,7,12,25,29,32,34,35,36,37,38,39,42,43,46,47,48,53,55,57,58,59,62,64,65,66,67,68,69,70,71,72,73,74,75,76,77,80,81,82,96,129,195,222,223,224,225,231,239,243,245,254,255,257,265,267,275,277,279,281,287],target_nam:34,targetin:[254,255],task1:[92,97,285,288],task1_evq:97,task1_handl:92,task1_init:92,task1_prio:92,task1_sanity_checkin_itvl:97,task1_sem:92,task1_stack:92,task1_stack_s:92,task2:[92,285,288],task2_handl:92,task2_init:92,task2_prio:92,task2_sem:92,task2_stack:92,task2_stack_s:92,task:[9,11,55,64,77,80,81,82,84,85,87,89,90,91,92,93,95,96,98,100,130,134,139,169,202,211,214,216,219,225,233,236,251,258,264,274,275,277,280,282,285,286,288,292],task_l:238,task_prior:[224,225],tasknam:12,taskstat:[64,78,80,81,82,131,133,236,285,288],tbd:[253,276],tc_case_fail_arg:231,tc_case_fail_cb:231,tc_case_init_arg:231,tc_case_init_cb:231,tc_case_pass_arg:231,tc_case_pass_cb:231,tc_print_result:[231,232],tc_restart_arg:231,tc_restart_cb:231,tc_suite_init_arg:231,tc_suite_init_cb:231,tc_system_assert:231,tck:256,tcp:[256,260],tdi:256,tdo:256,teach:243,team:[4,181,244],technic:[10,235],technolog:[21,135],tee:[1,34,35,37,38,39,40,41,42,43,44,45,46,47,48,49,50,51,52,53,54,57,58,59,62,275],telee02:264,telee02_boot:264,telemetri:254,telenor:264,teli:[254,255],tell:[30,55,140,155,193,195,199,222,223,225,235,249,251,254,255,262,270,274,276],telnet:[241,268,282,289],tem:278,temperatur:[159,206,278],templat:[7,45,246,267,275,282],temporari:[20,97,128,179],temporarili:[91,97],ten:190,term:[3,128,134,152,186,189,269],termin:[2,4,7,8,10,12,20,21,27,59,82,130,154,155,156,160,161,164,171,173,174,176,179,241,247,249,252,253,256,258,259,260,261,262,263,264,268,280,282,289],terminato:156,termintor:156,terribl:[7,246],test:[4,6,12,39,50,57,58,59,61,64,67,71,75,80,81,82,128,130,131,181,208,209,222,225,226,227,228,229,230,231,232,233,236,239,241,247,253,254,255,256,258,259,261,266,269,274,276,286,289,292],test_assert:[227,228,230,267],test_assert_fat:[226,267],test_cas:[226,267],test_case_1:228,test_case_2:228,test_case_3:228,test_case_nam:[227,228],test_datetime_parse_simpl:267,test_datetime_suit:267,test_json:267,test_json_util:267,test_project:44,test_suit:[227,228,267],test_suite_nam:230,testbench:[7,61],testcas:[7,267],testnam:75,testutil:[7,180,267],text:[39,48,69,89,130,171,214,222,229,260,285,288],textual:1,tgt:129,tgz:4,than:[3,7,14,20,29,72,89,91,92,93,96,98,99,100,101,128,132,152,163,166,179,190,194,211,214,222,224,226,228,241,243,247,253,254,255,259,276,282,289],thank:30,thee:96,thei:[1,6,20,29,30,61,84,87,89,90,92,93,98,99,128,129,134,169,179,192,222,223,225,231,234,240,249,250,251,253,254,255,264,265,267,269,270,272,274,278],their_key_dist:27,them:[2,9,55,89,93,98,99,160,177,179,195,222,223,225,243,247,249,254,255,256,267,268,269,276,277,292],themselv:[89,92,253],theori:[55,225],therebi:[98,140],therefor:[20,90,128,148,152,160,243,271],thi:[1,2,3,4,5,6,7,8,9,10,11,12,14,18,20,21,22,23,24,25,26,27,29,30,31,32,33,34,41,43,52,53,55,57,58,59,60,61,63,64,66,71,72,80,81,82,83,84,85,86,87,88,89,90,91,92,93,94,95,96,97,98,99,100,101,128,129,130,132,134,135,136,137,138,140,141,142,143,146,152,154,155,156,158,159,160,161,162,164,166,168,169,171,172,173,174,175,176,178,179,180,181,182,183,185,186,187,188,190,192,193,194,195,196,199,200,201,202,203,204,205,206,207,208,209,210,211,212,214,215,216,217,219,221,222,223,224,225,227,228,229,230,231,232,233,234,235,236,238,239,240,241,242,243,244,245,246,247,248,249,250,251,252,253,254,255,256,257,258,259,260,261,262,263,264,265,267,268,269,270,271,274,275,276,277,278,279,280,281,282,284,285,286,287,288,289,290,292],thing:[1,10,21,24,26,55,61,90,93,96,97,134,187,206,222,254,255,267,270,274,275,276,280,282],thingi:[207,241,242,289,290],thingy_boot:282,thingy_debug:[241,242,282,289,290],thingy_my_sensor:282,think:[10,128,276],third:[6,19,100,247,249,256,268,276],thorough:270,those:[1,31,32,39,55,57,58,59,61,93,96,128,137,141,222,234,270,274,275,276],though:[89,128,179,187,211,222],thought:276,thread:[9,246,256,260,262],three:[2,11,19,59,61,89,128,130,166,205,222,223,225,238,243,246,248,249,255,256,262,264],through:[21,23,61,62,89,99,128,133,140,146,151,154,155,156,161,164,173,174,181,190,199,211,236,248,250,252,255,256,258,262,267,268,274,275,276,279,281,284],throughout:[1,93,267],throughput:21,thrown:6,thu:[89,93,98,128,134,173,174,186,187,190,243],tick:[84,86,91,96,97,98,100,130,187,192,214,243,258,259,275,282],ticker:84,ticket:10,tickl:[97,194],tid:[77,275,285,288],tie:222,tied:152,ties:[89,246],time:[1,7,9,10,11,12,19,20,21,22,25,27,31,34,43,57,58,59,60,61,77,82,83,84,87,89,92,93,96,97,98,99,128,130,136,140,151,160,161,179,181,194,206,214,222,223,234,238,240,241,243,246,249,251,253,254,255,259,261,264,267,268,274,275,276,278,282,284,289],time_datetim:[222,282],time_datetime_test:267,time_in_flight:89,timeout:[20,27,64,65,66,67,68,69,70,71,72,73,74,75,76,77,80,81,82,87,91,98,187,239,275],timer:[24,84,86,87,93,97,181,189,194,211,282],timer_0:24,timer_4:264,timer_5:24,timer_ev_cb:[258,282],timer_interrupt_task:238,timer_num:192,timestamp:[72,206],timev:100,timezon:[100,267],timo:87,timo_func:84,timtest:[7,61],ting:[254,255],tini:[262,288],tinycbor:[7,277],tinycrypt:7,tinyprintf:101,tip:97,titl:[8,287],tlm:254,tlv:[27,128],tmp:[57,59,80,82,169,222],tmpstr:282,tmr:192,todo:[61,179,254,255],togeth:[1,43,55,61,89,137,179,222,250,262,276],toggl:[7,99,186,238,243,258],token:[75,92,98,214,271],told:195,too:[20,89,92,100,134,160,161,179,182,224,275],took:260,tool:[1,2,3,5,6,7,9,10,12,13,39,54,57,58,61,62,63,66,78,79,80,81,92,93,94,96,133,134,223,224,225,231,235,236,238,239,241,242,245,246,247,256,257,262,264,265,267,268,269,270,271,276,277,282,284,286,287,289,290,292],toolbox:2,toolchain:[2,3,5,7,12,33,59,63,236,239,247,257,268,284,287,292],toolkit:3,tools_1:[57,58,59,81,82],top:[1,10,12,35,61,89,99,134,173,187,224,247,254,255,267,276],topic:1,total:[9,55,64,65,66,67,68,69,70,71,72,73,74,75,76,77,80,81,82,89,99,101,128,179,259,261,264,276],tour:248,track:[19,21,22,100,128,179],tradeoff:222,trail:[89,128],trailer:128,transact:[20,187,190],transfer:[22,190,275],transform:179,transit:128,translat:[186,254],transmiss:[20,27,190,193,218,264],transmit:[29,31,130,187,190,264],transmitt:193,transport:[20,21,27,80,130,133,225,239,246,247,256,260,275,276,277,279,281,284],travers:[89,154,155,156,161,164],traverse_dir:[154,155,156,161,164],treat:[140,200],tree:[1,6,7,50,55,61,93,159,246],tri:[3,64,65,66,67,68,69,70,71,72,73,74,75,76,77,80,81,82,129,136,224,264],trial:93,tricki:99,trig:186,trigger:[6,10,87,186],trim:89,trip:97,triplet:206,troubleshoot:[223,224],truncat:[157,169,170,172],truncate_test:267,trust:[22,27,275],tt_chr_f:253,tt_svc_type_p:253,ttl:[247,288],tty:[8,258,268,275,278,285,288],ttys002:66,ttys003:66,ttys005:286,ttys012:[285,288],ttys10:8,ttys2:[8,258,268,278,285,288],ttys5:8,ttyusb0:[10,66,247],ttyusb2:[8,268,285,288],ttyusb:[8,258,268,278,285,288],tu_any_fail:[232,267],tu_case_init_fn_t:231,tu_case_report_fn_t:231,tu_config:[231,232],tu_init:231,tu_restart_fn_t:231,tu_suite_init_fn_t:231,tupl:100,turn:[24,134,181,182,186,222,236,246,247,257,258,261,269,270,278,285],tutiori:[73,76],tutori:[2,3,6,7,8,10,12,21,23,59,77,207,208,212,213,214,231,235,236,238,239,243,245,246,247,248,249,250,251,252,253,254,255,256,258,259,260,261,262,263,264,267,268,274,275,276,277,278,279,280,281,282,285,286,288],tv_sec:[100,267,282],tv_usec:[100,267,282],tvp:100,tweak:151,two:[2,3,10,12,18,19,21,22,23,27,31,43,45,50,55,61,66,89,90,91,92,93,95,99,100,128,130,132,173,179,187,205,206,214,220,222,223,224,225,235,236,238,243,246,247,249,251,254,255,256,258,259,260,261,262,263,264,267,268,269,270,271,272,275,276,277,278,281,282,285,288],tx_data:275,tx_done:193,tx_func:193,tx_len:275,tx_off:275,tx_phys_mask:27,tx_power_level:[27,29],tx_time_on_air:264,txbuf:190,txd:264,txpower:264,txrx:190,txrx_cb:190,txt:[70,153,157,160,163,170,171,172,242,290],type:[1,7,8,10,12,19,20,23,27,29,30,31,39,43,45,46,53,55,57,58,59,61,66,84,89,90,93,96,99,128,130,133,160,161,176,177,179,186,190,193,199,200,204,205,207,210,212,214,217,224,225,226,227,228,229,230,235,238,239,241,242,243,246,247,249,250,251,252,253,254,256,259,260,261,262,264,267,268,269,270,271,274,275,276,280,281,282,285,286,288,289,290],typedef:[26,87,90,97,99,100,130,150,186,190,192,193,199,206,214],typic:[3,9,21,26,31,55,61,89,92,93,94,97,128,130,134,173,174,181,183,186,187,190,205,206,222,223,225,231,249,254,255,267],tz_dsttime:[100,267],tz_minuteswest:[100,267],u8_len:136,uart0:[130,275,286],uart1:275,uart:[7,8,21,55,96,130,134,188,217,236,241,246,247,259,260,261,262,263,264,275,282,289],uart_0_pin_rx:275,uart_0_pin_tx:275,uart_bitbang:[188,259],uart_flow_control_non:130,uart_hal:[7,260,261,262],uart_rx_char:193,uartno:275,ubuntu:[4,6,7,57,80],uci:23,udev:260,udp:66,uext:288,uicr:23,uid:254,uint16:[27,28],uint16_max:27,uint16_t:[20,89,90,91,97,98,99,128,135,140,141,179,187,190,199,206,217,223,251,274,275,276],uint32:[27,71],uint32_max:27,uint32_t:[84,86,89,90,91,98,99,100,128,135,140,148,152,153,157,158,160,162,163,168,171,172,174,175,179,182,184,187,189,190,192,194,205,206,208,223],uint64:27,uint64_t:199,uint8:27,uint8_max:27,uint8_t:[23,32,87,89,90,91,93,97,99,128,130,134,135,140,148,152,153,154,155,156,160,161,162,163,164,168,171,174,179,182,184,185,187,190,193,199,205,206,208,217,223,249,251,254,255,275,276],uint_max:204,uinteg:[199,204],ultim:251,umbrella:222,unabl:[2,179,256,259,260,263],unaccept:20,unadorn:20,unam:2,unc_t:214,unchang:[93,179],unconfirm:264,und:[27,30],undefin:[82,182,225],under:[4,7,10,11,12,20,26,34,55,61,71,101,129,134,214,253,256,260,261,263,275,276],underli:[96,134,140,152,160,161,180,181,190,206],underlin:244,understand:[7,100,206,222,234,235,239,264,269,276],understood:[160,226],underwai:128,undesir:92,undirect:[27,249],unexpect:[20,154,155,156,161,164,167],unexpectedli:[20,267],unicast:31,unicod:151,unidirect:27,unifi:134,uniform:[29,59],uniformli:62,uninstal:7,unint32:71,uninterpret:225,union:[179,199,251],uniqu:[9,19,32,93,179,182,205,223,224,225,254,264],unit:[1,7,20,27,39,51,57,58,59,84,99,128,225,267,292],unittest:[7,45,55,61,225,246,267,275],univers:193,unix:[2,59,152,235],unknown:[20,224],unlabel:275,unless:[27,99,128,173,187,195,225,275,276],unlicens:21,unlik:[20,90,267],unlink:[58,60,81,83,153,161,166,169],unlink_test:267,unlock:[206,211],unmet:93,unpack:[57,59],unplug:263,unpredict:161,unprovis:31,unregist:210,unresolv:[181,267],unrespons:20,unset:[50,128],unsign:[99,199,223,263,282],unspecifi:[20,42],unstabl:[57,58,80,81],unsuccess:187,unsupport:[20,253],unsur:179,unsync:26,untar:4,until:[20,26,61,86,87,89,92,98,130,140,179,187,190,193,249,254,255,264,269],unuesd:252,unus:[71,274,275,276],unwritten:128,updat:[2,4,15,20,27,30,36,37,49,52,57,58,59,60,80,81,83,89,128,142,179,225,250,252,258,259,265,267,274,276,277,282],upgrad:[2,39,56,59,79,93,128,130,235,236,241,247,256,268,289,292],uplink:264,uplink_cntr:264,uplink_freq:264,upload:[10,43,70,71,152,195,222,239,259],upon:[1,3,10,26,55,89,128,179,223,252],upper:[23,179,193,225],uppercas:209,upstream:132,uri:[27,29,133],url:[27,254,267,269],url_bodi:254,url_body_len:254,url_schem:254,url_suffix:254,usabl:[1,90,93,246,254],usag:[1,9,57,58,59,62,80,81,82,89,99,134,135,152,173,179,187,206,214,219,223,225,243,264,275,286],usart6_rx:288,usart6_tx:288,usb:[2,3,8,21,42,66,236,238,239,243,247,256,257,259,260,261,262,263,264,268,276,278,284,285,287,288],usbmodem14211:66,usbmodem14221:66,usbmodem401322:8,usbseri:[8,258,268,275,278,285,288],usbttlseri:247,use:[1,4,5,6,7,8,11,12,14,19,20,21,22,24,27,30,32,41,45,50,51,55,56,58,59,61,64,65,66,67,68,69,70,71,72,73,74,75,76,77,79,81,82,84,86,87,93,94,96,98,99,128,129,130,131,134,136,140,141,151,152,165,166,169,173,176,177,179,180,187,190,192,199,200,201,202,203,204,205,206,207,208,209,210,211,214,215,216,219,220,222,223,224,225,231,235,236,237,238,239,240,241,242,243,245,246,247,249,250,251,252,254,255,256,257,258,259,262,264,265,267,268,270,271,274,275,276,277,278,281,282,284,285,286,287,288,289,290],use_wl:27,use_wl_inita:27,usec:[86,278,282],used:[6,7,10,11,12,19,20,22,23,24,27,29,30,31,34,46,49,61,66,72,84,86,89,90,91,93,98,99,100,101,128,129,130,135,136,140,143,151,152,156,179,184,187,188,190,192,194,199,206,207,208,214,222,223,224,225,226,227,228,229,230,233,234,235,240,243,247,249,251,252,253,254,255,256,264,267,268,269,270,276,277,278],useful:[3,20,92,171,208,246,269],user:[1,2,4,6,7,8,9,18,20,22,24,48,55,58,59,61,78,80,81,82,84,87,89,90,93,94,97,128,130,131,134,135,140,146,152,173,182,190,191,192,193,213,222,223,224,225,232,235,238,253,256,262,264,268,269,270,271,275,276,282,288],user_defined_head:89,user_hdr:89,user_hdr_len:89,user_id:[224,225],user_manu:235,user_pkthdr_len:89,usernam:[10,48,59,269],uses:[2,4,6,7,8,12,14,20,21,22,23,24,30,32,55,65,66,67,68,69,70,71,72,73,74,75,76,77,78,86,87,93,97,100,101,128,130,131,132,133,134,136,140,151,152,179,181,186,187,205,206,207,208,210,211,214,216,220,224,225,231,233,236,238,239,251,252,253,256,258,261,268,269,271,275,277,278,279,282,285,288],using:[1,2,4,6,7,8,11,12,19,20,21,24,26,27,28,29,31,33,36,37,43,44,57,58,59,60,61,63,66,76,80,81,82,83,84,86,87,89,91,92,94,95,96,97,98,99,100,101,128,129,134,140,143,145,150,151,152,160,179,181,186,187,189,190,192,194,199,208,209,211,214,222,223,225,227,228,230,231,235,236,238,239,241,242,243,244,246,247,253,255,256,257,258,259,260,261,262,263,264,267,268,274,275,276,277,279,282,286,287,289,290],usr:[4,6,11,36,57,58,59,60,80,81,82,83],usu:95,usual:[24,89,90,101,134,203,205],utc:[68,100,267],utctim:100,utf:29,util:[7,11,20,21,31,92,101,130,151,152,188,190,205,225,236,267],util_cbmem:282,util_cbmem_test:7,util_crc:[282,286,288],util_mem:[7,256,258,259,260,261,262,263,264,268,278,282,285,286,288],util_pars:[264,278,282],uuid128:[27,29,251,253,255],uuid128_is_complet:[27,29],uuid16:[27,28,29,251,274,276],uuid16_is_complet:[27,29],uuid32:[27,29],uuid32_is_complet:[27,29],uuid:[27,28,29,30,32,66,251,253,255,274,276,277],uvp:100,v10:282,v14:260,v25:260,va_arg:208,va_list:[226,229],val:[23,24,39,50,57,58,59,61,93,129,183,186,190,200,205,223,224,225,236,254,255,258,264,275,277],valid:[20,39,50,53,57,58,59,61,66,72,89,128,135,140,150,152,169,176,177,179,187,190,206,251,267,275,276],valu:[1,4,7,12,20,23,24,27,28,29,30,37,39,42,46,50,53,57,58,59,61,62,64,65,66,68,71,72,75,80,81,82,85,89,90,93,98,99,100,128,129,134,174,175,179,182,186,187,190,191,192,193,194,199,205,207,209,211,214,222,223,236,238,239,241,247,250,251,252,253,254,255,265,269,270,274,275,276,278,279,281,282,284,289],valuabl:269,value1:[50,225],value2:[50,225],valuen:225,vanilla:151,vari:[9,89,96,128],variabl:[1,4,11,24,34,37,50,59,61,62,65,89,90,99,129,130,173,199,205,206,207,208,211,219,222,226,229,235,243,249,251,264,269,270,277,278,279,282],variant:[22,95,186],variat:12,varieti:[4,252],variou:[23,24,61,89,128,132,134,181,252,257,264],vdd:276,vector:278,vendor:269,ver:[1,7,55,197,198,235,247,256,268,269,270,271,275,276],ver_len:198,ver_str:198,verb:62,verbos:[1,7,34,35,37,38,39,40,41,42,43,44,45,46,47,48,49,50,51,52,53,54,57,58,59,62,256,268,275],veri:[1,9,31,55,89,99,101,128,179,207,241,244,245,253,258,259,269,276,277,289],verif:22,verifi:[22,57,59,80,82,128,179,181,208,222,239,243,259,260,261,263,264,267,276,277],versa:[8,222],version:[1,2,4,6,7,10,11,12,21,22,34,37,39,41,43,47,55,56,60,79,83,84,130,140,179,195,197,198,205,222,225,235,236,239,241,242,247,255,256,258,259,260,261,262,263,264,268,272,275,276,278,282,285,288,289,290],via:[8,20,26,42,55,89,90,128,130,134,152,154,155,156,161,164,173,174,176,179,180,181,187,211,214,222,223,225,239,247,248,249,251,259,261,264,269,275,276,278,279,281,284],vice:[8,222],vid:260,view:[1,7,10,12,30,50,62,66,209,213,214,222,223,225,242,269,276,281,290],vim:59,vin:278,violat:20,viper:11,virtual:[66,183,186],virtualbox:256,visibl:[2,28],visit:[39,57,58,59],visual:[5,13,242,290],visualstudio:12,vol:22,volatil:260,voltag:[134,136,181,191,260,276],volum:[29,151],vscode:12,vtref:[259,261,264,276],vvp:100,wai:[2,3,9,21,30,31,59,61,84,87,92,99,100,130,152,186,187,188,205,222,224,244,269,270,271,275,276],wait:[84,85,86,87,89,91,92,98,99,136,182,187,190,225,238,243,262,264,274,275,276,284],waitin:91,wake:[85,89,92,98,99,182,211,243],wakeup:[99,211],walk:[89,99,146,150,179,205,276],wall:6,wallclock:[84,100],wanda:81,want:[1,3,11,18,50,57,58,59,60,61,80,83,84,85,89,90,91,92,97,98,99,128,129,130,150,152,169,186,205,206,207,210,223,234,236,240,241,246,248,249,251,253,254,255,256,257,259,260,261,262,264,265,267,269,275,276,279,289,292],warn:[1,6,34,35,37,38,39,40,41,42,43,44,45,46,47,48,49,50,51,52,53,54,57,58,59,62,224,251,259,275],warranti:[4,241,242,256,275,276,282,289,290],watch:246,watchdog:[92,97,191],watchpoint:[256,260],wdog:67,wear:246,wear_level_test:267,wearabl:9,web:[235,244],webfreak:12,websit:244,welcom:[8,134,245,268,275,278],well:[8,22,40,55,89,90,96,98,128,129,134,195,226,234,250,264,275,276],were:[29,73,89,128,181,222,270,274,275],werror:[6,50],wes:264,west:100,wfi:260,wget:[57,59,80,82],what:[7,8,20,41,55,96,98,135,140,173,174,179,207,208,222,225,237,243,249,252,253,254,255,267,270,274,275,276],whatev:[23,98,268],wheel:[8,235],when:[1,2,6,7,8,10,12,14,20,22,23,24,26,29,34,35,37,38,39,40,41,42,43,44,45,46,47,48,49,50,51,52,53,54,55,57,58,59,61,62,66,72,81,84,85,86,87,88,89,90,91,92,93,94,96,97,98,99,100,128,129,130,131,134,140,141,142,145,151,152,154,155,156,160,161,162,164,169,171,173,174,179,186,187,190,192,193,195,199,202,206,207,208,210,211,212,214,217,220,222,223,224,225,229,231,233,236,238,239,241,243,244,246,247,248,249,252,253,254,255,256,259,260,262,263,267,269,270,271,275,276,277,278,279,280,281,282,286,289],whenev:[21,26,90,134,179,199,210,251,253,282],where:[8,9,10,11,22,29,31,35,37,50,55,59,60,61,83,89,90,93,95,96,99,128,129,130,140,141,142,145,148,150,179,186,189,190,193,198,199,205,222,224,225,236,243,253,254,255,258,259,264,268,275,276,278,285,288],wherea:[89,270],whether:[10,12,22,84,87,90,100,128,140,155,187,190,191,207,208,209,211,212,213,214,223,225,233,249,251,253,267,278,280,281,282],which:[1,2,4,8,10,11,14,19,20,21,30,32,34,39,55,57,58,59,61,62,66,80,81,82,84,85,86,89,90,92,93,96,97,98,99,100,101,128,129,134,135,137,140,150,151,152,179,182,183,186,187,190,192,195,199,206,208,222,223,224,226,229,232,233,235,239,241,243,249,250,251,252,253,254,255,256,264,267,268,269,270,275,276,286,289],white:[22,27],whitelist:27,who:10,whole:135,whose:[61,62,179,211],why:[10,243],wide:[21,222],wifi:[7,268],wifi_connect:268,wifi_init:268,wifi_request_scan:268,wikipedia:[187,190],winc1500_wifi:268,window:[5,6,7,9,12,27,56,66,78,79,93,130,239,241,247,256,258,259,260,261,262,263,264,268,278,285,288,289],winusb:[260,262,288],wipe:144,wire:[8,187,190,264,275,276,288],wireless:21,wish:[6,10,173,174,187,243,269,287],withdraw:10,within:[1,12,20,31,41,55,89,93,94,96,128,134,140,145,148,150,173,174,179,181,186,197,199,205,208,209,210,214,223,231,243,252,262,267,269,275],without:[6,10,22,24,28,30,90,128,152,161,173,174,179,180,205,214,221,222,223,225,239,256,267,275,276,280],wno:6,won:[8,222,276],wonder:276,word:[6,55,89,92,98,128,179,190,241,242,251,256,269,282,289,290],word_siz:190,work:[2,4,8,10,11,22,24,55,61,62,85,89,91,92,93,95,96,98,99,128,130,134,135,160,181,223,235,236,240,243,246,247,250,256,258,264,267,272,274,275,276,279,281,284],work_stack:243,work_stack_s:243,work_task:243,work_task_handl:243,work_task_prio:243,workaround:10,workspac:[1,2,11,39,57,58,59,60,80,82,83],workspaceroot:12,world:[12,21,193,249,254,255,257,271,292],worri:92,worth:[1,94,275],would:[5,12,58,59,81,82,84,89,92,98,128,130,137,140,181,186,187,190,202,220,222,223,231,243,246,262,264,267,269,270,275,276,284,288],wrap:[100,223,258],wrapper:87,write:[1,9,14,20,28,61,64,65,80,81,82,94,128,129,130,134,135,136,140,141,142,146,151,152,157,158,168,170,172,173,174,181,184,186,187,193,195,197,200,201,202,203,205,218,223,229,238,243,245,250,252,253,264,266,275,276,277,284],write_cmd_rx:[76,236],write_cmd_tx:[76,236],write_config:[157,170],write_id:172,write_req_rx:[76,236],write_req_tx:[76,236],write_rsp_rx:[76,236],write_rsp_tx:[76,236],written:[11,20,23,59,82,92,128,140,141,142,145,150,156,157,160,163,169,170,171,173,174,179,187,190,251,253,258,270],wrong:[42,276],wsl:[12,59],www:[101,235,241,242,247,256,275,276,282,288,289,290],x86:[4,12],x86_64:[241,242,256,282,289,290],xml:[7,88,129],xpf:4,xpsr:[256,260,262],xtal_32768:93,xtal_32768_synth:24,xxx:[6,93,99,135],xxx_branch_0_8_0:[269,270],xxx_branch_1_0_0:[269,270],xxx_branch_1_0_2:[269,270],xxx_branch_1_1_0:[269,270],xxx_branch_1_1_2:[269,270],xxx_branch_1_2_0:[269,270],xxx_branch_1_2_1:[269,270],xxxx:181,xzf:[57,59,60,82,83],yai:275,yaml:11,year:31,yes:[22,264],yesno:27,yet:[7,92,96,239,246,269,270,276],yield:92,yml:[1,6,7,41,43,50,52,53,55,61,94,95,101,129,130,135,136,152,173,180,205,207,214,222,223,224,225,235,236,238,246,247,256,258,264,265,267,268,269,271,272,275,276,277,278,282],you:[1,3,4,5,6,7,8,9,10,11,12,18,19,30,33,34,35,39,41,43,45,46,47,50,51,52,53,54,55,57,58,59,60,61,63,64,66,68,76,80,81,82,83,84,92,93,94,95,96,101,128,129,130,131,132,134,137,138,140,141,142,146,155,160,161,163,169,171,173,174,180,181,183,186,187,189,199,202,205,206,207,209,210,211,214,215,216,219,220,221,222,223,224,225,231,234,236,238,239,241,242,243,244,245,246,247,248,249,250,251,252,253,254,255,256,257,258,259,260,261,262,263,264,265,267,268,269,270,271,274,276,277,278,279,280,281,282,284,285,286,287,288,289,290,292],your:[1,3,4,6,8,10,19,30,39,50,52,55,56,58,59,60,61,70,71,79,81,82,83,84,92,93,94,95,96,97,99,131,132,133,134,135,136,138,140,151,173,181,205,207,214,220,222,224,225,231,238,239,240,241,242,244,245,246,247,248,249,250,252,253,254,255,257,258,264,265,270,274,275,276,277,279,280,284,285,287,288,289,290,292],yourself:[2,10,30,92,93,248,275,292],ype:[254,255],yym:6,zadig:[260,262,288],zero:[12,24,84,89,90,93,99,100,144,148,150,157,169,170,175,182,186,187,190,191,192,193,199,215,217,218,219,225,243,253,254,255,257,264,267,268,269,282,292],zip:[4,259,276],zone:100},titles:["&lt;no title&gt;","Concepts","Everything You Need in a Docker Container","Setup &amp; Get Started","Installing the Cross Tools for ARM","Native Installation","Installing Native Toolchain","Creating Your First Mynewt Project","Using the Serial Port with Mynewt OS","Mynewt Documentation","FAQ","Contributing to Newt or Newtmgr Tools","Developing Mynewt Applications with Visual Studio Code","Appendix","NimBLE Host ATT Client Reference","NimBLE Host GAP Reference","NimBLE Host GATT Client Reference","NimBLE Host GATT Server Reference","NimBLE Host","NimBLE Host Identity Reference","NimBLE Host Return Codes","BLE User Guide","NimBLE Security","Configure device ddress","Configure clock for controller","NimBLE Setup","Respond to <em>sync</em> and <em>reset</em> events","GAP API for btshell","GATT feature API for btshell","Advertisement Data Fields","API for btshell app","Bluetooth Mesh","Sample application","Mynewt Newt Tool Documentation","newt build","newt clean","newt complete","newt create-image","newt debug","newt help","newt info","newt install","newt load","newt mfg","newt new","newt pkg","newt resign-image","newt run","newt size","newt sync","newt target","newt test","newt upgrade","newt vals","newt version","Newt Tool Guide","Install","Installing Newt on Linux","Installing Newt on Mac OS","Installing Newt on Windows","Installing Previous Releases of Newt","Theory of Operations","Command Structure","Mynewt Newt Manager Documentation","Command List","newtmgr config","newtmgr conn","newtmgr crash","newtmgr datetime","newtmgr echo","newtmgr fs","newtmgr image","newtmgr log","newtmgr mpstat","newtmgr reset","newtmgr run","newtmgr stat","newtmgr taskstat","Newt Manager Guide","Install","Installing Newtmgr on Linux","Installing Newtmgr on Mac OS","Installing Newtmgr on Windows","Installing Previous Releases of Newtmgr","Callout","Scheduler","CPU Time","Event Queues","Heap","Mbufs","Memory Pools","Mutex","Apache Mynewt Operating System Kernel","BSP Porting","Porting Mynewt to a new CPU Architecture","Porting Mynewt to a new MCU","Porting Mynewt OS","Sanity","Semaphore","Task","OS Time","Baselibc","&lt;no title&gt;","&lt;no title&gt;","&lt;no title&gt;","&lt;no title&gt;","&lt;no title&gt;","&lt;no title&gt;","&lt;no title&gt;","&lt;no title&gt;","&lt;no title&gt;","&lt;no title&gt;","&lt;no title&gt;","&lt;no title&gt;","&lt;no title&gt;","&lt;no title&gt;","&lt;no title&gt;","&lt;no title&gt;","&lt;no title&gt;","&lt;no title&gt;","&lt;no title&gt;","&lt;no title&gt;","&lt;no title&gt;","&lt;no title&gt;","&lt;no title&gt;","&lt;no title&gt;","&lt;no title&gt;","&lt;no title&gt;","Bootloader","Config","Console","Customizing Newt Manager Usage with mgmt","Newt Manager","Using the OIC Framework","Drivers","flash","mmc","elua","lua_init","lua_main","Flash Circular Buffer (FCB)","fcb_append","fcb_append_finish","fcb_append_to_scratch","fcb_clear","fcb_getnext","fcb_init","fcb_is_empty","fcb_offset_last_n","fcb_rotate","fcb_walk","The FAT File System","File System Abstraction","fs_close","fs_closedir","fs_dirent_is_dir","fs_dirent_name","fs_filelen","fs_getpos","fs_mkdir","fs_open","fs_opendir","struct fs_ops","fs_read","fs_readdir","fs_register","fs_rename","fs/fs Return Codes","fs_seek","fs_unlink","fs_write","fsutil_read_file","fsutil_write_file","Newtron Flash Filesystem (nffs)","struct nffs_area_desc","struct nffs_config","nffs_detect","nffs_format","nffs_init","Internals of nffs","Other File Systems","Hardware Abstraction Layer","BSP","Creating New HAL Interfaces","Flash","hal_flash_int","GPIO","I2C","Using HAL in Your Libraries","OS Tick","SPI","System","Timer","UART","Watchdog","Image Manager","imgmgr_module_init","imgr_ver_parse","imgr_ver_str","JSON","json_encode_object_entry","json_encode_object_finish","json_encode_object_key","json_encode_object_start","json_read_object","Logging","Sensor API","Creating and Configuring a Sensor Device","Sensor Device Driver","Mynewt Sensor Framework Overview","Sensor Listener API","Sensor Manager API","OIC Sensor Support","Sensor Shell Command","Shell","shell_cmd_register","shell_evq_set","shell_nlip_input_register","shell_nlip_output","shell_register","shell_register_app_cmd_handler","shell_register_default_module","Split Images","Statistics Module","Validation and Error Messages","System Configuration and Initialization","TEST_ASSERT","TEST_CASE","TEST_CASE_DECL","TEST_PASS","TEST_SUITE","testutil","tu_init","tu_restart","OS User Guide","Blinky, your \u201cHello World!\u201d, on STM32F303 Discovery","Enabling Newt Manager in Your Application","How to Define a Target","How to Use Event Queues to Manage Multiple Events","Over-the-Air Image Upgrade","Pin Wheel Modifications to \u201cBlinky\u201d on STM32F3 Discovery","SEGGER RTT Console","SEGGER SystemView","Tasks and Priority Management","Try Markdown","Bluetooth Low Energy","Set up a bare bones NimBLE application","Use HCI access to NimBLE controller","BLE Peripheral Project","Advertising","BLE Peripheral App","Characteristic Access","GAP Event callbacks","Service Registration","BLE Eddystone","BLE iBeacon","Blinky, your \u201cHello World!\u201d, on Arduino Zero","Project Blinky","Enabling The Console and Shell for Blinky","Blinky, your \u201cHello World!\u201d, on Arduino Primo","Blinky, your \u201cHello World!\u201d, on STM32F4-Discovery","Blinky, your \u201cHello World!\u201d, on a nRF52 Development Kit","Blinky, your \u201cHello World!\u201d, on Olimex","Blinky, your \u201cHello World!\u201d, on RedBear Nano 2","LoRaWAN App","How to Reduce Application Code Size","Other","Write a Test Suite for a Package","Enable Wi-Fi on Arduino MKR1000","Adding Repositories to your Project","Create a Repo out of a Project","Accessing a private repository","Upgrade a repo","Air Quality Sensor Project","Air quality sensor project via Bluetooth","Air quality sensor project","Adding an Analog Sensor on nRF52","Adding OIC Sensor Support to the bleprph_oic Application","Enabling an Off-Board Sensor in an Existing Application","Enabling OIC Sensor Data Monitoring in the sensors_test Application","Changing the Default Configuration for a Sensor","Enabling OIC Sensor Data Monitoring","Developing an Application for an Onboard Sensor","Sensors","Sensor Tutorials Overview","Project Slinky using the Nordic nRF52 Board","Project Sim Slinky","Project Slinky","Project Slinky Using Olimex Board","SEGGER RTT Console","SEGGER SystemView","Tooling","Tutorials"],titleterms:{"abstract":[152,181],"default":[243,258,280],"function":[93,100,101,137,140,195,199,206,208,210,211,225,231,243,251,253,277,280],"import":235,"new":[7,44,94,95,179,183,250,280,282,285,286,288],"public":23,"return":[20,136,138,139,141,142,143,144,145,146,147,148,149,150,153,154,155,156,157,158,159,160,161,163,164,165,166,167,168,169,170,171,172,176,177,178,196,197,198,200,201,202,203,204,215,216,217,218,219,220,221,226,227,228,229,230,232,233],"switch":[101,243],"try":[244,267],Adding:[58,81,223,269,276,277,280,282],For:4,The:[151,258],Use:[2,236,238,247,258,275,282,285,288],Used:206,Uses:205,Using:[8,57,80,89,130,133,188,278,282,288],acceleromet:280,access:[247,251,271],adafruit:10,adc:276,add:[66,93,254,255,274,275,276,277,282],addit:[269,276],address:[19,23,30,254,255],administr:10,advertis:[27,29,30,249,254,255],air:[239,273,274,275],all:238,ambigu:224,analog:276,apach:[9,31,92],api:[27,28,30,84,85,86,87,88,89,90,91,97,98,99,100,129,130,151,152,173,180,182,183,184,186,187,189,190,191,192,193,194,205,206,210,211,282],app:[9,30,61,222,242,247,250,264,282,284,290],app_get_light:277,app_set_light:277,appendix:[13,93],applic:[7,12,32,92,205,206,207,222,235,236,238,243,246,247,254,255,256,258,259,260,261,262,263,264,265,268,276,277,278,279,280,282,285,288],apt:[57,80],architectur:94,arduino:[8,256,259,268],area:[173,179,224],argument:[138,139,141,142,143,144,145,146,147,148,149,150,153,154,155,156,157,158,159,160,161,163,164,165,166,168,169,170,171,172,176,177,196,197,198,200,201,202,203,204,215,216,217,218,219,221,226,227,228,229,230,232,233],arm:4,artifact:61,assert:267,assign:224,associ:12,att:[14,20],attach:247,attribut:[30,253],autocomplet:36,avail:[27,28,39,43,50,257,269,284,287],bare:246,baselibc:101,bash:36,basic:92,beacon:[254,255],bearer:31,begin:[30,249],being:251,belong:30,between:268,binari:[57,59,80,82],bit:6,ble:[21,246,248,250,254,255,276,277],blehci:247,bleprph_gap_ev:252,bleprph_oic:277,blink:235,blink_rigado:48,blinki:[7,235,240,256,257,258,259,260,261,262,263],block:179,bluetooth:[21,31,245,247,274],bluez:247,bno055:278,bno055_log:208,bno055_stat:208,board:[96,207,256,259,260,261,262,263,264,268,276,277,278,279,285,288],bone:246,boot:[128,222],bootload:[128,247,256,259,260,261,262,263,264,268,278,282,285,288],branch:[58,81],brew:6,bsp:[53,93,96,182,224],btmgmt:247,btmon:247,btshell:[27,28,30],buffer:140,bug:10,build:[7,9,12,34,55,61,235,236,240,243,246,247,256,258,259,260,261,262,263,264,268,276,277,278,279,280,282,285,286,288],cach:179,call:280,callback:252,callout:[84,238],can:10,cannot:280,categori:292,chang:[33,63,280],channel:27,characterist:[30,248,251],check:[57,58,59,80,81,82,93,97,128,211],choos:267,circular:140,clean:35,clear:263,cli:[129,275],client:[14,16],clock:24,close:264,code:[10,12,20,93,94,167,223,265,267],collect:179,command:[12,27,28,39,43,50,62,64,66,132,208,213,214,236,247,275,286],committ:10,commun:[8,236,258],compil:94,complet:[36,214],compon:[21,269],comput:[57,80,268,278,282],concept:[1,222],conclus:[246,254,255,276],condit:225,config:[65,129],configur:[1,12,23,24,27,28,30,129,151,205,206,207,208,211,224,225,235,236,254,255,258,280],conflict:225,congratul:267,conn:66,connect:[27,30,236,239,241,247,256,258,259,260,261,262,263,264,268,276,277,278,279,282,285,286,288,289],consider:243,consol:[130,214,223,241,258,268,278,282,289],contain:2,content:[33,63],context:243,contribut:11,control:[24,247,254,255,277,278,279,284],copi:[93,277],core:[20,92,96],cpu:[86,94,96],crash:67,creat:[7,37,89,93,94,183,207,235,236,239,246,247,250,254,255,256,259,260,261,262,263,264,267,268,270,275,276,277,278,279,282,285,286,288],creation:92,cross:4,crystal:24,current:222,custom:[97,131,236],data:[29,100,137,140,152,173,179,187,195,199,206,208,210,211,214,231,249,264,277,278,279,280,281,282],datetim:68,ddress:23,debian:[57,80],debug:[12,38,61,93],debugg:[4,12],declar:223,decod:199,defin:[12,93,208,223,237],definit:[185,224,225],delet:[66,277],depend:[7,61,93,96,135,136,180,181,235,236,258,270,277,282],descript:[34,35,37,38,40,41,42,43,44,45,46,47,48,49,50,51,52,53,65,66,67,68,69,70,71,72,73,74,75,76,77,84,85,86,87,88,90,91,96,97,98,99,100,101,130,134,137,140,151,152,173,181,182,184,185,186,187,189,190,191,192,193,194,195,199,214,222,231,278],descriptor:[30,248,253,269],design:[134,181],detail:223,detect:179,determin:251,develop:[12,261,282],devic:[2,23,27,30,129,206,207,208,239,247,277,278,279,280,284],direct:30,directori:[61,179],disabl:27,discov:30,discoveri:[27,235,240,260],disk:179,disk_op:152,displai:30,docker:2,document:[10,33,63],doe:269,download:[11,57,61,80,93,235,240,264,276],driver:[134,206,208,275,276,280],duplic:224,echo:69,eddyston:254,edit:10,editor:10,elua:137,empti:[254,255],emul:278,enabl:[2,27,36,214,222,223,236,258,268,277,278,279,281,282],encod:199,endif:[207,208],energi:245,enhanc:173,enter:246,environ:11,equip:243,eras:259,error:224,establish:[30,247,268],etap:276,event:[26,87,238,252,258],everyth:[2,264,276],exampl:[8,20,21,26,34,35,37,38,39,43,44,45,46,47,48,50,51,53,54,65,66,67,68,69,70,71,72,73,74,75,76,77,87,92,129,134,135,136,138,139,141,142,143,144,145,146,147,148,149,150,151,153,154,155,156,157,159,160,161,163,164,166,168,169,170,171,172,176,177,181,185,193,197,198,200,201,202,203,204,215,217,218,220,221,224,225,226,227,228,230,231,232,233,238],execut:[6,235,240,241,242,259,260,261,263,264,276,286,289,290],exist:[236,258,269,278],explor:7,express:224,extend:[27,282],extens:[2,12],extern:[235,256,268],faq:10,fat:151,fcb:140,fcb_append:141,fcb_append_finish:142,fcb_append_to_scratch:143,fcb_clear:144,fcb_getnext:145,fcb_init:146,fcb_is_empti:147,fcb_offset_last_n:148,fcb_rotat:149,fcb_walk:150,featur:[7,10,21,22,28,31,92],fetch:[7,256,268],field:29,file:[93,135,136,151,152,153,154,155,156,157,158,159,160,161,162,163,164,165,166,167,168,169,170,171,172,174,175,176,177,178,179,180,223,228,270,277,280,282],filesystem:[152,173],fill:93,find:269,first:[7,9],flag:[34,35,37,38,39,40,41,42,43,44,45,46,47,48,49,50,51,52,53,54,65,66,67,68,69,70,71,72,73,74,75,76,77],flash:[93,128,135,140,173,179,184,224,259,263],format:[128,179],framework:[133,208,209,236,281],from:[57,58,59,80,81,82,130,277,279,280],fs_close:153,fs_closedir:154,fs_dirent_is_dir:155,fs_dirent_nam:156,fs_filelen:157,fs_getpo:158,fs_mkdir:159,fs_op:162,fs_open:160,fs_opendir:161,fs_read:163,fs_readdir:164,fs_regist:165,fs_renam:166,fs_seek:168,fs_unlink:169,fs_write:170,fsutil_read_fil:171,fsutil_write_fil:172,ft232h:8,full:130,futur:173,gap:[15,27,252],garbag:179,gatt:[16,17,28,274],gcc:6,gdb:6,gener:[22,30,134,181,225,238],get:[3,57,80,208],git:[10,59],global:[34,35,37,38,39,40,41,42,43,44,45,46,47,48,49,50,51,52,53,54,65,66,67,68,69,70,71,72,73,74,75,76,77],gpio:186,guarante:252,guid:[21,55,78,234],hal:[96,183,188,275],hal_flash_int:185,hal_i2c:187,handler:[129,205,214],hardcod:23,hardwar:[23,181,235,241,242,264,276,278,289,290],have:10,hci:[20,247],header:[14,15,16,17,19,20,89,135,136,152,153,154,155,156,157,158,159,160,161,162,163,164,165,166,167,168,169,170,171,172,174,175,176,177,178,180,223,277,280],heading3:244,heading4:244,heap:88,hello:[235,256,259,260,261,262,263],help:[39,214],high:128,hold:223,homebrew:[58,81],host:[14,15,16,17,18,19,20,254,255],how:[10,101,225,237,238,265,269,277,280],i2c:187,ibeacon:255,ident:19,identifi:269,ignor:224,imag:[10,37,46,71,128,195,222,235,236,239,240,247,259,260,261,262,263,264,268,276,277,278,279,280,282,285,288],imgmgr_module_init:196,imgr_ver_pars:197,imgr_ver_str:198,implement:[94,134,205,208,223],includ:[30,208,223,253],indefinit:[254,255],info:40,inform:214,initi:[30,135,136,173,206,208,223,225,243,280],inod:179,input:[130,214],instal:[2,4,5,6,11,12,36,41,56,57,58,59,60,79,80,81,82,83,235,264,276],instead:282,integr:128,interfac:[180,183,206],intern:[173,179],interrupt:238,introduct:[9,14,15,16,17,18,19,20,31,55,93,238,248,267],invalid:224,invok:132,issu:10,join:264,json:199,json_encode_object_entri:200,json_encode_object_finish:201,json_encode_object_kei:202,json_encode_object_start:203,json_read_object:204,kei:[22,27],kernel:92,kit:261,l2cap:[20,27],laptop:10,latest:[57,58,59,80,81,82],launch:[242,290],layer:181,led:[235,240],legaci:27,level:[128,205,239],libc:6,librari:[188,235],like:10,limit:128,line:214,link:4,linker:93,linux:[2,4,6,8,11,57,60,80,83],lis2dh12_onb:207,list:[10,64,101,137,140,195,199,206,210,211,222,231,244,254,255,278,282],listen:[210,282],load:[42,236,247,256,259,260,261,262,263,268,277,278,279,280,282,285,288],loader:222,log:[72,205,208,239],look:211,lorawan:264,low:245,lua_init:138,lua_main:139,mac:[2,4,6,8,11,58,60,81,83],macro:100,main:[243,258,277,280,282],make:10,manag:[9,10,20,55,63,78,131,132,195,211,236,238,243],manual:[57,80],map:[93,128],markdown:244,master:[58,81],mbuf:89,mcu:[93,95,96],measur:173,memori:[90,263],merg:10,mesh:[21,31],messag:224,method:[23,57,80],mfg:43,mgmt:131,mingw:59,minim:130,miscellan:173,mkr1000:268,mmc:136,model:31,modif:240,modifi:[236,258,277,282],modul:[214,223],monitor:[247,279,281],more:[55,235],move:179,mpstat:73,mqueue:89,msy:89,msys2:59,multipl:[12,152,223,224,238],mutex:91,my_sensor_app:282,mynewt:[2,7,8,9,10,12,23,31,33,58,63,81,92,93,94,95,96,130,209,246,269,277,279,284],mynewt_v:[207,208],name:[30,214,223,225],nano:263,nativ:[5,6],need:[2,235,240,241,242,264,269,275,276,278,289,290],newt:[2,9,10,11,12,33,34,35,36,37,38,39,40,41,42,43,44,45,46,47,48,49,50,51,52,53,54,55,57,58,59,60,63,78,131,132,236],newtmgr:[11,65,66,67,68,69,70,71,72,73,74,75,76,77,80,81,82,83,132,214,223,236,239,285,286,288],newtron:173,next:[6,278],nff:[173,179],nffs_area_desc:174,nffs_config:175,nffs_detect:176,nffs_format:177,nffs_init:178,nimbl:[14,15,16,17,18,19,20,21,22,25,246,247,254,255],node:31,nordic:[8,285],normal:89,note:[55,100,137,138,139,141,142,143,144,145,146,147,148,149,150,153,156,158,159,160,161,165,166,168,170,171,174,175,196,197,198,216,223,226,229,276],notnul:224,nrf52:[261,276,278,285],nrf52_adc:276,nrf52dk:[8,10],nrf:23,object:[179,206,235,240,241,242,257,264,276,289,290],off:[207,278],oic:[133,212,277,279,281,284],oicmgr:236,olimex:[262,288],omgr_app_init:277,onboard:[207,282],onto:[256,268],open:[247,264],openocd:4,oper:[55,61,92,128,187,190,222],option:[236,259],orient:27,ota:264,other:[7,12,180,236,266,270],out:[267,269,270],output:[48,53,130],over:[214,239],overrid:[224,225],overview:[64,209,248,249,250,252,257,277,280,281,284,287],own:10,pack:2,packag:[1,7,57,61,80,93,96,130,180,205,206,209,224,225,236,246,256,267,268,275,277,278,282],packet:89,passiv:30,patch:10,peer:[20,30],perform:30,peripher:[248,250],persist:129,pin:240,pkg:[45,93],platform:[8,181],poll:[206,211],pool:[89,90],port:[8,93,94,95,96,264],preempt:243,prerequisit:[7,236,238,239,243,247,250,256,257,258,259,260,261,262,263,268,277,278,279,280,281,282,284,285,286,287,288,292],preview:[33,63],previou:[60,83],primo:259,principl:[134,181],prioriti:[224,243],privaci:22,privat:271,pro:8,process:[214,258],produc:[6,61],profil:[236,239,286],project:[1,7,10,12,21,235,236,246,247,248,256,257,258,259,260,261,262,263,264,268,269,270,273,274,275,276,285,286,287,288],prompt:214,protect:263,protocol:[214,236,254,255],provis:31,pull:[2,10],put:238,qualiti:[273,274,275],queri:[285,288],question:10,queue:[87,238,258],ram:179,random:23,rate:206,rational:55,read:[30,206,208,251,280,282],reboot:280,rebuild:[11,282],reconfigur:207,recoveri:128,redbear:263,reduc:[10,239,265],refer:[14,15,16,17,19,20,225],referenc:225,regist:[97,180,208,211,214,223,278],registr:253,releas:[57,58,59,60,80,81,82,83],renam:179,repo:[269,270,272],repositori:[7,10,55,269,270,271,276],represent:179,request:10,requir:93,reset:[26,74,128],resign:46,resolut:270,resolv:[61,225,270],respond:26,restrict:224,retriev:[222,223],review:[243,251],round:240,rtt:[241,282,289],run:[7,12,47,75,241,242,256,258,286,289,290],runtim:[23,129],safeti:152,sampl:[32,278,280],saniti:97,satisfi:93,scale:267,scan:30,schedul:85,scratch:179,script:[2,93],section:223,secur:[20,22,27],segger:[4,241,242,289,290],select:2,semaphor:98,semiconductor:8,send:[30,247,264],sensor:[206,207,208,209,210,211,212,213,273,274,275,276,277,278,279,280,281,282,283,284],sensor_read:282,sensors_test:279,sequenc:222,serial:[8,214,247,258,268,285,288],server:17,servic:[30,248,253,274,276],set:[6,11,30,57,80,93,205,206,208,224,225,236,246,249,253,258,275,277,280,286],settl:24,setup:[3,8,25,241,242,268,289,290],shell:[208,213,214,258,282],shell_cmd_regist:215,shell_evq_set:216,shell_nlip_input_regist:217,shell_nlip_output:218,shell_regist:219,shell_register_app_cmd_handl:220,shell_register_default_modul:221,should:270,show:[30,66],sign:[128,235,259,260,261,262,263,264,268,276,285,288],signatur:251,sim:286,simul:7,singl:222,size:[10,48,265],skeleton:282,slinki:[285,286,287,288],slot:128,smart:[277,279,284],softwar:[10,242,290],some:10,sourc:[7,11,55,57,59,80,82,236,254,255,275,277],space:179,special:100,specif:[94,270],specifi:[180,225],spi:190,split:222,stack:[243,254,255],start:[3,247,268],startup:93,stat:[76,208,223],state:[128,129,222],statist:223,statu:128,step:[11,239,257,277,278,279,280,282,287],stm32f303:235,stm32f3:[235,240],stm32f4:260,storag:27,struct:[152,162,174,175],structur:[62,100,137,140,152,173,179,195,199,206,210,211,214,231],stub:130,studio:12,stuff:275,sub:66,submit:10,suit:267,summari:20,support:[2,31,61,96,152,181,209,212,235,236,277,278,281,282],swap:128,sync:[26,49,254,255],syscfg:[205,222,225,277],sysinit_app:225,system:[24,55,92,151,152,180,191,224,225],systemview:[242,290],tabl:223,talk:268,tap:[58,81],target:[1,23,50,61,93,235,236,237,240,241,242,246,247,250,256,258,259,260,261,262,263,264,268,276,278,282,285,286,288,289,290],task:[12,97,99,224,238,243,276],taskstat:77,tcp:268,templat:93,termin:278,test:[7,51,93,267,275],test_assert:226,test_cas:[227,228],test_case_decl:228,test_pass:229,test_suit:230,testutil:231,theori:[61,187,190,222],thingi:282,thread:152,through:223,tick:189,time:[24,86,100],timer:[192,238,258],togeth:238,tool:[4,11,33,55,59,82,291],toolchain:[4,6],topolog:31,transport:[214,236],tree:275,tu_init:232,tu_restart:233,tutori:[222,257,284,287,292],type:[206,208,211,278],uart:193,undefin:224,under:267,undirect:30,unifi:222,unlink:179,updat:11,upgrad:[52,57,58,80,81,222,239,272],upload:258,usag:[34,35,36,37,38,39,40,41,42,43,44,45,46,47,48,49,50,51,52,53,54,65,66,67,68,69,70,71,72,73,74,75,76,77,131,140],usb2:2,use:[10,57,80,89,92,269],user:[21,234],using:[10,55,285,288],val:53,valid:224,valu:[136,138,139,141,142,143,144,145,146,147,148,149,150,153,154,155,156,157,158,159,160,161,163,164,165,166,168,169,170,171,172,176,177,178,196,197,198,200,201,202,203,204,206,208,215,216,217,218,219,220,221,224,225,226,227,228,229,230,232,233,277,280],variabl:223,vector:128,verif:[128,280],verifi:280,version:[54,57,58,59,80,81,82,269,270],via:[268,274,282],view:[277,278,279,282],violat:224,virtualbox:2,visual:12,wait:[254,255],want:[10,235],watch:[235,240],watchdog:194,water:276,welcom:9,what:[10,235,240,269],wheel:240,where:270,why:[89,92,269],window:[2,4,8,11,59,60,82,83],work:12,workspac:12,world:[235,256,259,260,261,262,263],would:10,wrapper:2,write:[30,33,63,179,251,263,267],yml:[93,270],you:[2,235,240,275],your:[2,7,9,11,12,57,80,180,188,223,235,236,243,256,259,260,261,262,263,267,268,269,278,282,286],zero:256}})
\ No newline at end of file
diff --git a/master/sitemap.xml b/master/sitemap.xml
index 6e171931f..e995c872e 100644
--- a/master/sitemap.xml
+++ b/master/sitemap.xml
@@ -4,7 +4,7 @@
     
     <url>
      <loc>http://mynewt.apache.org/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
     
@@ -13,13 +13,13 @@
         
     <url>
      <loc>http://mynewt.apache.org/pages/ble/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
         
     <url>
      <loc>http://mynewt.apache.org/pages/securitybullets/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
         
@@ -28,7 +28,7 @@
     
     <url>
      <loc>http://mynewt.apache.org/quick-start/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
     
@@ -36,7 +36,7 @@
     
     <url>
      <loc>http://mynewt.apache.org/about/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
     
@@ -44,7 +44,7 @@
     
     <url>
      <loc>http://mynewt.apache.org/talks/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
     
@@ -52,7 +52,7 @@
     
     <url>
      <loc>http://mynewt.apache.org/download/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
     
@@ -60,7 +60,7 @@
     
     <url>
      <loc>http://mynewt.apache.org/community/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
     
@@ -68,7 +68,7 @@
     
     <url>
      <loc>http://mynewt.apache.org/events/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
     
@@ -76,7 +76,7 @@
     
     <url>
      <loc>http://mynewt.apache.org/documentation/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
     
@@ -85,7 +85,7 @@
         
     <url>
      <loc>http://mynewt.apache.org/os/introduction/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
         
@@ -97,7 +97,7 @@
         
     <url>
      <loc>http://mynewt.apache.org/os/get_started/vocabulary/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
         
@@ -133,7 +133,7 @@
         
     <url>
      <loc>http://mynewt.apache.org/known_issues/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
         
@@ -143,37 +143,37 @@
         
     <url>
      <loc>http://mynewt.apache.org/newt/install/prev_releases/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
         
     <url>
      <loc>http://mynewt.apache.org/newtmgr/prev_releases/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
         
     <url>
      <loc>http://mynewt.apache.org/faq/go_env/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
         
     <url>
      <loc>http://mynewt.apache.org/faq/ide/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
         
     <url>
      <loc>http://mynewt.apache.org/faq/how_to_edit_docs/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
         
     <url>
      <loc>http://mynewt.apache.org/faq/answers/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
         
diff --git a/sitemap.xml b/sitemap.xml
index 6e171931f..e995c872e 100644
--- a/sitemap.xml
+++ b/sitemap.xml
@@ -4,7 +4,7 @@
     
     <url>
      <loc>http://mynewt.apache.org/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
     
@@ -13,13 +13,13 @@
         
     <url>
      <loc>http://mynewt.apache.org/pages/ble/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
         
     <url>
      <loc>http://mynewt.apache.org/pages/securitybullets/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
         
@@ -28,7 +28,7 @@
     
     <url>
      <loc>http://mynewt.apache.org/quick-start/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
     
@@ -36,7 +36,7 @@
     
     <url>
      <loc>http://mynewt.apache.org/about/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
     
@@ -44,7 +44,7 @@
     
     <url>
      <loc>http://mynewt.apache.org/talks/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
     
@@ -52,7 +52,7 @@
     
     <url>
      <loc>http://mynewt.apache.org/download/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
     
@@ -60,7 +60,7 @@
     
     <url>
      <loc>http://mynewt.apache.org/community/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
     
@@ -68,7 +68,7 @@
     
     <url>
      <loc>http://mynewt.apache.org/events/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
     
@@ -76,7 +76,7 @@
     
     <url>
      <loc>http://mynewt.apache.org/documentation/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
     
@@ -85,7 +85,7 @@
         
     <url>
      <loc>http://mynewt.apache.org/os/introduction/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
         
@@ -97,7 +97,7 @@
         
     <url>
      <loc>http://mynewt.apache.org/os/get_started/vocabulary/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
         
@@ -133,7 +133,7 @@
         
     <url>
      <loc>http://mynewt.apache.org/known_issues/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
         
@@ -143,37 +143,37 @@
         
     <url>
      <loc>http://mynewt.apache.org/newt/install/prev_releases/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
         
     <url>
      <loc>http://mynewt.apache.org/newtmgr/prev_releases/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
         
     <url>
      <loc>http://mynewt.apache.org/faq/go_env/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
         
     <url>
      <loc>http://mynewt.apache.org/faq/ide/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
         
     <url>
      <loc>http://mynewt.apache.org/faq/how_to_edit_docs/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
         
     <url>
      <loc>http://mynewt.apache.org/faq/answers/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
         
diff --git a/v0_9_0/sitemap.xml b/v0_9_0/sitemap.xml
index 4ddec4347..607027af3 100644
--- a/v0_9_0/sitemap.xml
+++ b/v0_9_0/sitemap.xml
@@ -4,7 +4,7 @@
     
     <url>
      <loc>http://mynewt.apache.org/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
     
@@ -12,7 +12,7 @@
     
     <url>
      <loc>http://mynewt.apache.org/quick-start/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
     
@@ -20,7 +20,7 @@
     
     <url>
      <loc>http://mynewt.apache.org/about/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
     
@@ -28,7 +28,7 @@
     
     <url>
      <loc>http://mynewt.apache.org/download/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
     
@@ -36,7 +36,7 @@
     
     <url>
      <loc>http://mynewt.apache.org/community/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
     
@@ -44,7 +44,7 @@
     
     <url>
      <loc>http://mynewt.apache.org/events/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
     
@@ -53,7 +53,7 @@
         
     <url>
      <loc>http://mynewt.apache.org/os/introduction/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
         
@@ -65,7 +65,7 @@
         
     <url>
      <loc>http://mynewt.apache.org/os/get_started/vocabulary/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
         
@@ -101,7 +101,7 @@
         
     <url>
      <loc>http://mynewt.apache.org/known_issues/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
         
@@ -111,13 +111,13 @@
         
     <url>
      <loc>http://mynewt.apache.org/faq/how_to_edit_docs/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
         
     <url>
      <loc>http://mynewt.apache.org/faq/answers/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
         
diff --git a/v1_0_0/sitemap.xml b/v1_0_0/sitemap.xml
index 19d47ffb2..1eec8fbb9 100644
--- a/v1_0_0/sitemap.xml
+++ b/v1_0_0/sitemap.xml
@@ -4,7 +4,7 @@
     
     <url>
      <loc>http://mynewt.apache.org/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
     
@@ -13,7 +13,7 @@
         
     <url>
      <loc>http://mynewt.apache.org/pages/ble/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
         
@@ -22,7 +22,7 @@
     
     <url>
      <loc>http://mynewt.apache.org/quick-start/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
     
@@ -30,7 +30,7 @@
     
     <url>
      <loc>http://mynewt.apache.org/about/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
     
@@ -38,7 +38,7 @@
     
     <url>
      <loc>http://mynewt.apache.org/talks/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
     
@@ -46,7 +46,7 @@
     
     <url>
      <loc>http://mynewt.apache.org/download/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
     
@@ -54,7 +54,7 @@
     
     <url>
      <loc>http://mynewt.apache.org/community/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
     
@@ -62,7 +62,7 @@
     
     <url>
      <loc>http://mynewt.apache.org/events/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
     
@@ -71,7 +71,7 @@
         
     <url>
      <loc>http://mynewt.apache.org/os/introduction/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
         
@@ -83,7 +83,7 @@
         
     <url>
      <loc>http://mynewt.apache.org/os/get_started/vocabulary/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
         
@@ -119,7 +119,7 @@
         
     <url>
      <loc>http://mynewt.apache.org/known_issues/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
         
@@ -129,25 +129,25 @@
         
     <url>
      <loc>http://mynewt.apache.org/faq/go_env/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
         
     <url>
      <loc>http://mynewt.apache.org/faq/ide/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
         
     <url>
      <loc>http://mynewt.apache.org/faq/how_to_edit_docs/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
         
     <url>
      <loc>http://mynewt.apache.org/faq/answers/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
         
diff --git a/v1_1_0/sitemap.xml b/v1_1_0/sitemap.xml
index 80066ad87..4b1257948 100644
--- a/v1_1_0/sitemap.xml
+++ b/v1_1_0/sitemap.xml
@@ -4,7 +4,7 @@
     
     <url>
      <loc>http://mynewt.apache.org/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
     
@@ -13,13 +13,13 @@
         
     <url>
      <loc>http://mynewt.apache.org/pages/ble/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
         
     <url>
      <loc>http://mynewt.apache.org/pages/securitybullets/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
         
@@ -28,7 +28,7 @@
     
     <url>
      <loc>http://mynewt.apache.org/quick-start/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
     
@@ -36,7 +36,7 @@
     
     <url>
      <loc>http://mynewt.apache.org/about/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
     
@@ -44,7 +44,7 @@
     
     <url>
      <loc>http://mynewt.apache.org/talks/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
     
@@ -52,7 +52,7 @@
     
     <url>
      <loc>http://mynewt.apache.org/download/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
     
@@ -60,7 +60,7 @@
     
     <url>
      <loc>http://mynewt.apache.org/community/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
     
@@ -68,7 +68,7 @@
     
     <url>
      <loc>http://mynewt.apache.org/events/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
     
@@ -77,7 +77,7 @@
         
     <url>
      <loc>http://mynewt.apache.org/os/introduction/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
         
@@ -89,7 +89,7 @@
         
     <url>
      <loc>http://mynewt.apache.org/os/get_started/vocabulary/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
         
@@ -125,7 +125,7 @@
         
     <url>
      <loc>http://mynewt.apache.org/known_issues/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
         
@@ -135,25 +135,25 @@
         
     <url>
      <loc>http://mynewt.apache.org/faq/go_env/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
         
     <url>
      <loc>http://mynewt.apache.org/faq/ide/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
         
     <url>
      <loc>http://mynewt.apache.org/faq/how_to_edit_docs/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
         
     <url>
      <loc>http://mynewt.apache.org/faq/answers/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
         
diff --git a/v1_2_0/sitemap.xml b/v1_2_0/sitemap.xml
index 8a78b5bb0..9b85645d7 100644
--- a/v1_2_0/sitemap.xml
+++ b/v1_2_0/sitemap.xml
@@ -4,7 +4,7 @@
     
     <url>
      <loc>http://mynewt.apache.org/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
     
@@ -13,13 +13,13 @@
         
     <url>
      <loc>http://mynewt.apache.org/pages/ble/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
         
     <url>
      <loc>http://mynewt.apache.org/pages/securitybullets/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
         
@@ -28,7 +28,7 @@
     
     <url>
      <loc>http://mynewt.apache.org/quick-start/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
     
@@ -36,7 +36,7 @@
     
     <url>
      <loc>http://mynewt.apache.org/about/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
     
@@ -44,7 +44,7 @@
     
     <url>
      <loc>http://mynewt.apache.org/talks/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
     
@@ -52,7 +52,7 @@
     
     <url>
      <loc>http://mynewt.apache.org/download/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
     
@@ -60,7 +60,7 @@
     
     <url>
      <loc>http://mynewt.apache.org/community/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
     
@@ -68,7 +68,7 @@
     
     <url>
      <loc>http://mynewt.apache.org/events/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
     
@@ -77,7 +77,7 @@
         
     <url>
      <loc>http://mynewt.apache.org/os/introduction/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
         
@@ -89,7 +89,7 @@
         
     <url>
      <loc>http://mynewt.apache.org/os/get_started/vocabulary/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
         
@@ -125,7 +125,7 @@
         
     <url>
      <loc>http://mynewt.apache.org/known_issues/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
         
@@ -135,37 +135,37 @@
         
     <url>
      <loc>http://mynewt.apache.org/newt/install/prev_releases/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
         
     <url>
      <loc>http://mynewt.apache.org/newtmgr/prev_releases/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
         
     <url>
      <loc>http://mynewt.apache.org/faq/go_env/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
         
     <url>
      <loc>http://mynewt.apache.org/faq/ide/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
         
     <url>
      <loc>http://mynewt.apache.org/faq/how_to_edit_docs/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
         
     <url>
      <loc>http://mynewt.apache.org/faq/answers/</loc>
-     <lastmod>2018-03-02</lastmod>
+     <lastmod>2018-03-03</lastmod>
      <changefreq>daily</changefreq>
     </url>
         


 

----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on GitHub and use the
URL above to go to the specific comment.
 
For queries about this service, please contact Infrastructure at:
users@infra.apache.org


With regards,
Apache Git Services