You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@mynewt.apache.org by cc...@apache.org on 2016/11/22 03:25:39 UTC

[24/51] [abbrv] [partial] incubator-mynewt-core git commit: Remove non-Apache-compatible Nordic SDK files.

http://git-wip-us.apache.org/repos/asf/incubator-mynewt-core/blob/a1481cb2/hw/mcu/nordic/src/ext/nRF5_SDK_11.0.0_89a8197/components/libraries/simple_timer/app_simple_timer.c
----------------------------------------------------------------------
diff --git a/hw/mcu/nordic/src/ext/nRF5_SDK_11.0.0_89a8197/components/libraries/simple_timer/app_simple_timer.c b/hw/mcu/nordic/src/ext/nRF5_SDK_11.0.0_89a8197/components/libraries/simple_timer/app_simple_timer.c
deleted file mode 100644
index eef38ec..0000000
--- a/hw/mcu/nordic/src/ext/nRF5_SDK_11.0.0_89a8197/components/libraries/simple_timer/app_simple_timer.c
+++ /dev/null
@@ -1,187 +0,0 @@
-/* Copyright (c) 2015 Nordic Semiconductor. All Rights Reserved.
- *
- * The information contained herein is property of Nordic Semiconductor ASA.
- * Terms and conditions of usage are described in detail in NORDIC
- * SEMICONDUCTOR STANDARD SOFTWARE LICENSE AGREEMENT.
- *
- * Licensees are granted free, non-transferable use of the information. NO
- * WARRANTY of ANY KIND is provided. This heading must NOT be removed from
- * the file.
- *
- */
- 
-#include "app_simple_timer.h"
-#include "nrf.h"
-#include "app_util_platform.h"
-#include "app_error.h"
-#include "nrf_timer.h"
-#include "nrf_drv_timer.h"
-#include "sdk_common.h"
-
-/**@brief States of simple timer state machine.
- */
-typedef enum
-{
-    SIMPLE_TIMER_STATE_IDLE = 0,
-    SIMPLE_TIMER_STATE_INITIALIZED,
-    SIMPLE_TIMER_STATE_STOPPED,
-    SIMPLE_TIMER_STATE_STARTED
-}simple_timer_states_t;
-
-static app_simple_timer_mode_t            m_mode;                                               /**< Registered timer mode. */
-static app_simple_timer_timeout_handler_t m_timeout_handler          = NULL;                    /**< Registered time-out handler. */
-static void *                             mp_timeout_handler_context = NULL;                    /**< Registered time-out handler context. */
-static simple_timer_states_t              m_simple_timer_state       = SIMPLE_TIMER_STATE_IDLE; /**< State machine state. */
-
-#define APP_SIMPLE_TIMER_INSTANCE 1
-
-#if (APP_SIMPLE_TIMER_INSTANCE == 0)
-    #if (TIMER_CONFIG_MODE(0) != TIMER_MODE_MODE_Timer)
-        #error "Unsupported timer mode."
-    #endif
-    #if (TIMER_CONFIG_BIT_WIDTH(0) != TIMER_BITMODE_BITMODE_16Bit)
-        #error "Unsupported timer bit width."
-    #endif
-    const nrf_drv_timer_t SIMPLE_TIMER = NRF_DRV_TIMER_INSTANCE(0);
-#elif (APP_SIMPLE_TIMER_INSTANCE == 1)
-    #if (TIMER_CONFIG_MODE(1) != TIMER_MODE_MODE_Timer)
-        #error "Unsupported timer mode."
-    #endif
-    #if (TIMER_CONFIG_BIT_WIDTH(1) != TIMER_BITMODE_BITMODE_16Bit)
-        #error "Unsupported timer bit width."
-    #endif
-    const nrf_drv_timer_t SIMPLE_TIMER = NRF_DRV_TIMER_INSTANCE(1);
-#elif (APP_SIMPLE_TIMER_INSTANCE == 2)
-    #if (TIMER_CONFIG_MODE(2) != TIMER_MODE_MODE_Timer)
-        #error "Unsupported timer mode."
-    #endif
-    #if (TIMER_CONFIG_BIT_WIDTH(2) != TIMER_BITMODE_BITMODE_16Bit)
-        #error "Unsupported timer bit width."
-    #endif
-    const nrf_drv_timer_t SIMPLE_TIMER = NRF_DRV_TIMER_INSTANCE(2);
-#else
-    #error "Wrong timer instance id."
-#endif
-
-/**
- * @brief Handler for timer events.
- */
-static void app_simple_timer_event_handler(nrf_timer_event_t event_type, void * p_context)
-{
-    switch(event_type)
-    {
-        case NRF_TIMER_EVENT_COMPARE0:
-            if (m_mode == APP_SIMPLE_TIMER_MODE_SINGLE_SHOT)
-            {
-                m_simple_timer_state = SIMPLE_TIMER_STATE_STOPPED;
-            }
-
-            //@note: No NULL check required as performed in timer_start(...).
-            m_timeout_handler(mp_timeout_handler_context);
-            break;
-
-        default:
-            //Do nothing.
-            break;
-    }
-}
-
-uint32_t app_simple_timer_init(void)
-{
-    uint32_t err_code = NRF_SUCCESS;
-
-    err_code = nrf_drv_timer_init(&SIMPLE_TIMER, NULL, app_simple_timer_event_handler);
-
-    if(NRF_SUCCESS == err_code)
-    {
-        m_simple_timer_state = SIMPLE_TIMER_STATE_INITIALIZED;
-    }
-
-    return err_code;
-}
-
-uint32_t app_simple_timer_start(app_simple_timer_mode_t            mode, 
-                                app_simple_timer_timeout_handler_t timeout_handler,
-                                uint16_t                           timeout_ticks,
-                                void *                             p_context)
-{
-    uint32_t err_code = NRF_SUCCESS;
-    nrf_timer_short_mask_t timer_short;
-
-    VERIFY_PARAM_NOT_NULL(timeout_handler);
-
-    if (APP_SIMPLE_TIMER_MODE_REPEATED == mode)
-    {
-        timer_short = NRF_TIMER_SHORT_COMPARE0_CLEAR_MASK;
-    }
-    else if(APP_SIMPLE_TIMER_MODE_SINGLE_SHOT == mode)
-    {
-        timer_short = NRF_TIMER_SHORT_COMPARE0_STOP_MASK;
-    }
-    else
-    {
-        return NRF_ERROR_INVALID_PARAM;
-    }
-
-    if(SIMPLE_TIMER_STATE_IDLE == m_simple_timer_state)
-    {
-        return NRF_ERROR_INVALID_STATE;
-    }
-
-    if(SIMPLE_TIMER_STATE_STARTED == m_simple_timer_state)
-    {
-        err_code = app_simple_timer_stop();
-        APP_ERROR_CHECK(err_code);
-    }
-
-    if(SIMPLE_TIMER_STATE_STOPPED == m_simple_timer_state)
-    {
-        nrf_drv_timer_clear(&SIMPLE_TIMER);
-    }
-
-    m_mode                      = mode;
-    m_timeout_handler           = timeout_handler;
-    mp_timeout_handler_context  = p_context;
-
-    nrf_drv_timer_extended_compare(
-            &SIMPLE_TIMER, NRF_TIMER_CC_CHANNEL0, (uint32_t)timeout_ticks, timer_short, true);
-
-    if (m_simple_timer_state == SIMPLE_TIMER_STATE_STOPPED)
-    {
-        nrf_drv_timer_resume(&SIMPLE_TIMER);
-    }
-    else
-    {
-        nrf_drv_timer_enable(&SIMPLE_TIMER);
-    }
-
-
-    m_simple_timer_state = SIMPLE_TIMER_STATE_STARTED;
-
-    return NRF_SUCCESS;
-}
-
-uint32_t app_simple_timer_stop(void)
-{
-    if(SIMPLE_TIMER_STATE_STARTED == m_simple_timer_state)
-    {
-        nrf_drv_timer_pause(&SIMPLE_TIMER);
-
-        m_simple_timer_state = SIMPLE_TIMER_STATE_STOPPED;
-    }
-
-    return NRF_SUCCESS;
-}
-
-uint32_t app_simple_timer_uninit(void)
-{
-    uint32_t err_code = NRF_SUCCESS;
-
-    if(SIMPLE_TIMER_STATE_IDLE != m_simple_timer_state)
-    {
-        nrf_drv_timer_uninit(&SIMPLE_TIMER);
-        m_simple_timer_state = SIMPLE_TIMER_STATE_IDLE;
-    }
-
-    return err_code;
-}

http://git-wip-us.apache.org/repos/asf/incubator-mynewt-core/blob/a1481cb2/hw/mcu/nordic/src/ext/nRF5_SDK_11.0.0_89a8197/components/libraries/simple_timer/app_simple_timer.h
----------------------------------------------------------------------
diff --git a/hw/mcu/nordic/src/ext/nRF5_SDK_11.0.0_89a8197/components/libraries/simple_timer/app_simple_timer.h b/hw/mcu/nordic/src/ext/nRF5_SDK_11.0.0_89a8197/components/libraries/simple_timer/app_simple_timer.h
deleted file mode 100644
index 9bb6c59..0000000
--- a/hw/mcu/nordic/src/ext/nRF5_SDK_11.0.0_89a8197/components/libraries/simple_timer/app_simple_timer.h
+++ /dev/null
@@ -1,106 +0,0 @@
-/* Copyright (c) 2015 Nordic Semiconductor. All Rights Reserved.
- *
- * The information contained herein is property of Nordic Semiconductor ASA.
- * Terms and conditions of usage are described in detail in NORDIC
- * SEMICONDUCTOR STANDARD SOFTWARE LICENSE AGREEMENT.
- *
- * Licensees are granted free, non-transferable use of the information. NO
- * WARRANTY of ANY KIND is provided. This heading must NOT be removed from
- * the file.
- *
- */
- 
-/**@file
- *
- * @defgroup lib_driver_simple_timer Simple Timer
- * @{
- * @ingroup  app_common
- *
- * @brief    Simple timer module.
- *
- * Supported features and limitations:
- * - Two modes: single shot mode and repeated mode.
- * - No more than one timer can run simultaneously.
- * - The timer is hard-coded to use the TIMER1 peripheral and compare channel 0.
- */
-
-#ifndef TIMER_H__
-#define TIMER_H__
-
-#include <stdint.h>
-
-#ifdef __cplusplus
-extern "C" {
-#endif
-
-/**@brief Timer time-out handler type. */
-typedef void (*app_simple_timer_timeout_handler_t)(void * p_context);
-
-/**@brief Timer modes. */
-typedef enum
-{
-    APP_SIMPLE_TIMER_MODE_SINGLE_SHOT,   /**< The timer will expire only once. */
-    APP_SIMPLE_TIMER_MODE_REPEATED       /**< The timer will restart each time it expires. */
-} app_simple_timer_mode_t;
-
-/**@brief Function for configuring and setting up the timer hardware. 
- *
- * @note  Configuration parameters should be set in nrf_drv_config.h file.
- *        The TIMER1_CONFIG_MODE has to be set to NRF_TIMER_MODE_TIMER value.
- *        The TIMER1_CONFIG_BIT_WIDTH has to be set to NRF_TIMER_BIT_WIDTH_16 value.
- *
- * @retval NRF_SUCCESS             If the operation is successful.
- * @retval NRF_ERROR_INVALID_STATE If the operation fails because the timer is already initialized.
- * @retval NRF_ERROR_INVALID_PARAM If the operation fails because some configuration parameter is
- *                                 not valid.
- */
-uint32_t app_simple_timer_init(void);
-
-/**@brief Function for starting a timer.
- *
- * @note  If this function is called for a timer that is already running, the currently running 
- *        timer is stopped before starting the new one.
- *
- * @param[in] mode                 Timer mode (see @ref app_simple_timer_mode_t).
- * @param[in] timeout_handler      Function to be executed when the timer expires 
- *                                 (see @ref app_simple_timer_timeout_handler_t).
- * @param[in] timeout_ticks        Number of timer ticks to time-out event.
- * @param[in] p_context            General purpose pointer. Will be passed to the time-out handler 
- *                                 when the timer expires.
- * 
- * @retval NRF_SUCCESS             If the operation is successful.
- * @retval NRF_ERROR_INVALID_STATE If the operation fails because @ref app_simple_timer_init has not
- *                                 been called and the operation is not allowed in this state.
- * @retval NRF_ERROR_NULL          If the operation fails because timeout_handler is NULL.
- * @retval NRF_ERROR_INVALID_PARAM If the operation fails because "mode" parameter is not valid.
- */
- 
-uint32_t app_simple_timer_start(app_simple_timer_mode_t            mode,
-                                app_simple_timer_timeout_handler_t timeout_handler,
-                                uint16_t                           timeout_ticks,
-                                void *                             p_context);
-
-/**@brief Function for stopping the timer.
- *
- * @retval NRF_SUCCESS             If the operation is successful.
- */
-uint32_t app_simple_timer_stop(void);
-
-/**@brief Function for uninitializing the timer. Should be called also when the timer is not used
- *        anymore to reach lowest power consumption in system.
- *
- * @note  The function switches off the internal core of the timer to reach lowest power consumption
- *        in system. The startup time from this state may be longer compared to starting the timer
- *        from the stopped state.
- *
- * @retval NRF_SUCCESS             If the operation is successful.
- */
-uint32_t app_simple_timer_uninit(void);
-
-#ifdef __cplusplus
-}
-#endif
-
-#endif // TIMER_H__
-
-/** @} */

http://git-wip-us.apache.org/repos/asf/incubator-mynewt-core/blob/a1481cb2/hw/mcu/nordic/src/ext/nRF5_SDK_11.0.0_89a8197/components/libraries/slip/slip.c
----------------------------------------------------------------------
diff --git a/hw/mcu/nordic/src/ext/nRF5_SDK_11.0.0_89a8197/components/libraries/slip/slip.c b/hw/mcu/nordic/src/ext/nRF5_SDK_11.0.0_89a8197/components/libraries/slip/slip.c
deleted file mode 100644
index 8e5bad8..0000000
--- a/hw/mcu/nordic/src/ext/nRF5_SDK_11.0.0_89a8197/components/libraries/slip/slip.c
+++ /dev/null
@@ -1,112 +0,0 @@
-/* Copyright (c) 2015 Nordic Semiconductor. All Rights Reserved.
- *
- * The information contained herein is property of Nordic Semiconductor ASA.
- * Terms and conditions of usage are described in detail in NORDIC
- * SEMICONDUCTOR STANDARD SOFTWARE LICENSE AGREEMENT.
- *
- * Licensees are granted free, non-transferable use of the information. NO
- * WARRANTY of ANY KIND is provided. This heading must NOT be removed from
- * the file.
- *
- */
- 
-#include "slip.h"
-#include "nrf_error.h"
-
-#define SLIP_END             0300    /* indicates end of packet */
-#define SLIP_ESC             0333    /* indicates byte stuffing */
-#define SLIP_ESC_END         0334    /* ESC ESC_END means END data byte */
-#define SLIP_ESC_ESC         0335    /* ESC ESC_ESC means ESC data byte */
-
-
-uint32_t slip_encode(uint8_t * p_output,  uint8_t * p_input, uint32_t input_length, uint32_t output_buffer_length)
-{
-    uint32_t input_index;
-    uint32_t output_index;
-    
-    for (input_index = 0, output_index = 0; input_index < input_length && output_index < output_buffer_length; input_index++)
-    {
-        switch (p_input[input_index])
-        {
-            case SLIP_END:
-                p_output[output_index++] = SLIP_END;
-                p_output[output_index++] = SLIP_ESC_END;
-                break;
-            
-            case SLIP_ESC:
-                p_output[output_index++] = SLIP_ESC;
-                p_output[output_index++] = SLIP_ESC_ESC;
-                break;
-                
-            default:
-                p_output[output_index++] = p_input[input_index];
-        }
-    }
-    p_output[output_index++] = (uint8_t)SLIP_END;
-    p_output[output_index++] = (uint8_t)SLIP_END; // clarify that the packet has ended.
-    
-    return output_index;
-}
-
-
-uint32_t slip_decoding_add_char(uint8_t c, buffer_t * p_buf, slip_state_t * current_state)
-{   
-    switch (*current_state)
-    {
-        case SLIP_DECODING:
-            if (c == SLIP_END)
-            {
-                *current_state = SLIP_END_RECEIVED;
-            }
-            else if (c == SLIP_ESC)
-            {
-                *current_state = SLIP_END_RECEIVED;
-            }
-            else 
-            {
-                p_buf->p_buffer[p_buf->current_index++] = c;
-                p_buf->current_length++;
-            }
-            break;
-        
-        case SLIP_ESC_RECEIVED:
-            if (c == SLIP_ESC_ESC)
-            {
-                p_buf->p_buffer[p_buf->current_index++] = SLIP_ESC; 
-                p_buf->current_length++;  
-                *current_state = SLIP_DECODING;                
-            }
-            else
-            {
-                // violation of protocol
-                *current_state = SLIP_CLEARING_INVALID_PACKET;
-                return NRF_ERROR_INVALID_DATA;
-            }
-            break;
-            
-        case SLIP_END_RECEIVED:
-            if (c == SLIP_ESC_END)
-            {
-                p_buf->p_buffer[p_buf->current_index++] = SLIP_END;
-                p_buf->current_length++;
-                *current_state = SLIP_DECODING;
-            }
-            else 
-            {
-                // packet is finished
-                *current_state = SLIP_DECODING;                 
-                return NRF_SUCCESS;
-            }
-            break;       
-        
-        case SLIP_CLEARING_INVALID_PACKET:
-            if (c == SLIP_END)
-            {
-                *current_state = SLIP_DECODING;        
-                p_buf->current_index = 0;
-                p_buf->current_length = 0;
-            }
-            break;
-    } 
-    return NRF_ERROR_BUSY;
-}

http://git-wip-us.apache.org/repos/asf/incubator-mynewt-core/blob/a1481cb2/hw/mcu/nordic/src/ext/nRF5_SDK_11.0.0_89a8197/components/libraries/slip/slip.h
----------------------------------------------------------------------
diff --git a/hw/mcu/nordic/src/ext/nRF5_SDK_11.0.0_89a8197/components/libraries/slip/slip.h b/hw/mcu/nordic/src/ext/nRF5_SDK_11.0.0_89a8197/components/libraries/slip/slip.h
deleted file mode 100644
index ac8b7f8..0000000
--- a/hw/mcu/nordic/src/ext/nRF5_SDK_11.0.0_89a8197/components/libraries/slip/slip.h
+++ /dev/null
@@ -1,74 +0,0 @@
-/* Copyright (c) 2015 Nordic Semiconductor. All Rights Reserved.
- *
- * The information contained herein is property of Nordic Semiconductor ASA.
- * Terms and conditions of usage are described in detail in NORDIC
- * SEMICONDUCTOR STANDARD SOFTWARE LICENSE AGREEMENT.
- *
- * Licensees are granted free, non-transferable use of the information. NO
- * WARRANTY of ANY KIND is provided. This heading must NOT be removed from
- * the file.
- *
- */
- 
-#ifndef SLIP_H__
-#define SLIP_H__
-
-#include <stdint.h>
-#include "app_fifo.h"
-
-#ifdef __cplusplus
-extern "C" {
-#endif
-
-/** @file
- *
- * @defgroup slip SLIP encoding decoding
- * @{
- * @ingroup app_common
- *
- * @brief  This module encodes and decodes slip packages (RFC1055).
- *
- * @details The standard is described in https://tools.ietf.org/html/rfc1055
- */
-  
-typedef enum {
-    SLIP_DECODING,
-    SLIP_END_RECEIVED,
-    SLIP_ESC_RECEIVED,
-    SLIP_CLEARING_INVALID_PACKET,
-} slip_state_t;
-
-typedef struct {
-    uint8_t * p_buffer;
-    uint32_t current_index;
-    uint32_t current_length;
-    uint32_t len;
-} buffer_t; 
-  
-/**@brief Encodes a slip packet.
- * 
- * @details Note that the encoded output data will be longer than the input data. 
- *
- * @retval The length of the encoded packet. If it is smaller than the input length, an error has occurred. 
- */
-uint32_t slip_encode(uint8_t * p_output,  uint8_t * p_input, uint32_t input_length, uint32_t output_buffer_length);
-
-/**@brief Decodes a slip packet.
- * 
- * @details When decoding a slip packet, a state must be preserved. Initial state must be set to SLIP_DECODING.
- *
- * @retval NRF_SUCCESS when a packet is parsed. The length of the packet can be read out from p_buf->current_index
- * @retval NRF_ERROR_BUSY when packet is not finished parsing
- * @retval NRF_ERROR_INVALID_DATA when packet is encoded wrong. 
-           This moves the decoding to SLIP_CLEARING_INVALID_PACKET, and will stay in this state until SLIP_END is encountered.
- */
-uint32_t slip_decoding_add_char(uint8_t c, buffer_t * p_buf, slip_state_t * current_state);
-
-
-#ifdef __cplusplus
-}
-#endif
-
-#endif // SLIP_H__
-
-/** @} */

http://git-wip-us.apache.org/repos/asf/incubator-mynewt-core/blob/a1481cb2/hw/mcu/nordic/src/ext/nRF5_SDK_11.0.0_89a8197/components/libraries/timer/app_timer.c
----------------------------------------------------------------------
diff --git a/hw/mcu/nordic/src/ext/nRF5_SDK_11.0.0_89a8197/components/libraries/timer/app_timer.c b/hw/mcu/nordic/src/ext/nRF5_SDK_11.0.0_89a8197/components/libraries/timer/app_timer.c
deleted file mode 100644
index d19f009..0000000
--- a/hw/mcu/nordic/src/ext/nRF5_SDK_11.0.0_89a8197/components/libraries/timer/app_timer.c
+++ /dev/null
@@ -1,1152 +0,0 @@
-/* Copyright (c) 2012 Nordic Semiconductor. All Rights Reserved.
- *
- * The information contained herein is property of Nordic Semiconductor ASA.
- * Terms and conditions of usage are described in detail in NORDIC
- * SEMICONDUCTOR STANDARD SOFTWARE LICENSE AGREEMENT.
- *
- * Licensees are granted free, non-transferable use of the information. NO
- * WARRANTY of ANY KIND is provided. This heading must NOT be removed from
- * the file.
- *
- */
-
-#include "app_timer.h"
-#include <stdlib.h>
-#include "nrf.h"
-#include "nrf_soc.h"
-#include "app_error.h"
-#include "nrf_delay.h"
-#include "app_util_platform.h"
-#include "sdk_common.h"
-
-#define RTC1_IRQ_PRI            APP_IRQ_PRIORITY_LOW                        /**< Priority of the RTC1 interrupt (used for checking for timeouts and executing timeout handlers). */
-#define SWI_IRQ_PRI             APP_IRQ_PRIORITY_LOW                        /**< Priority of the SWI  interrupt (used for updating the timer list). */
-
-// The current design assumes that both interrupt handlers run at the same interrupt level.
-// If this is to be changed, protection must be added to prevent them from interrupting each other
-// (e.g. by using guard/trigger flags).
-STATIC_ASSERT(RTC1_IRQ_PRI == SWI_IRQ_PRI);
-
-#define MAX_RTC_COUNTER_VAL     0x00FFFFFF                                  /**< Maximum value of the RTC counter. */
-
-#define APP_HIGH_USER_ID        0                                           /**< User Id for the Application High "user". */
-#define APP_LOW_USER_ID         1                                           /**< User Id for the Application Low "user". */
-#define THREAD_MODE_USER_ID     2                                           /**< User Id for the Thread Mode "user". */
-
-#define RTC_COMPARE_OFFSET_MIN  3                                           /**< Minimum offset between the current RTC counter value and the Capture Compare register. Although the nRF51 Series User Specification recommends this value to be 2, we use 3 to be safer.*/
-
-#define MAX_RTC_TASKS_DELAY     47                                          /**< Maximum delay until an RTC task is executed. */
-
-#ifdef NRF51
-#define SWI_IRQn SWI0_IRQn
-#define SWI_IRQHandler SWI0_IRQHandler
-#elif defined NRF52
-#define SWI_IRQn SWI0_EGU0_IRQn
-#define SWI_IRQHandler SWI0_EGU0_IRQHandler
-#endif
-
-/**@brief Timer node type. The nodes will be used form a linked list of running timers. */
-typedef struct
-{
-    uint32_t                    ticks_to_expire;                            /**< Number of ticks from previous timer interrupt to timer expiry. */
-    uint32_t                    ticks_at_start;                             /**< Current RTC counter value when the timer was started. */
-    uint32_t                    ticks_first_interval;                       /**< Number of ticks in the first timer interval. */
-    uint32_t                    ticks_periodic_interval;                    /**< Timer period (for repeating timers). */
-    bool                        is_running;                                 /**< True if timer is running, False otherwise. */
-    app_timer_mode_t            mode;                                       /**< Timer mode. */
-    app_timer_timeout_handler_t p_timeout_handler;                          /**< Pointer to function to be executed when the timer expires. */
-    void *                      p_context;                                  /**< General purpose pointer. Will be passed to the timeout handler when the timer expires. */
-    void *                      next;                                       /**< Pointer to the next node. */
-} timer_node_t;
-
-STATIC_ASSERT(sizeof(timer_node_t) == APP_TIMER_NODE_SIZE);
-
-/**@brief Set of available timer operation types. */
-typedef enum
-{
-    TIMER_USER_OP_TYPE_NONE,                                                /**< Invalid timer operation type. */
-    TIMER_USER_OP_TYPE_START,                                               /**< Timer operation type Start. */
-    TIMER_USER_OP_TYPE_STOP,                                                /**< Timer operation type Stop. */
-    TIMER_USER_OP_TYPE_STOP_ALL                                             /**< Timer operation type Stop All. */
-} timer_user_op_type_t;
-
-/**@brief Structure describing a timer start operation. */
-typedef struct
-{
-    uint32_t ticks_at_start;                                                /**< Current RTC counter value when the timer was started. */
-    uint32_t ticks_first_interval;                                          /**< Number of ticks in the first timer interval. */
-    uint32_t ticks_periodic_interval;                                       /**< Timer period (for repeating timers). */
-    void *   p_context;                                                     /**< General purpose pointer. Will be passed to the timeout handler when the timer expires. */
-} timer_user_op_start_t;
-
-/**@brief Structure describing a timer operation. */
-typedef struct
-{
-    timer_user_op_type_t op_type;                                             /**< Id of timer on which the operation is to be performed. */
-    timer_node_t *       p_node;
-    union
-    {
-        timer_user_op_start_t start;                                        /**< Structure describing a timer start operation. */
-    } params;
-} timer_user_op_t;
-
-STATIC_ASSERT(sizeof(timer_user_op_t) <= APP_TIMER_USER_OP_SIZE);
-STATIC_ASSERT(sizeof(timer_user_op_t) % 4 == 0);
-
-/**@brief Structure describing a timer user.
- *
- * @details For each user of the timer module, there will be a timer operations queue. This queue
- *          will hold timer operations issued by this user until the timer interrupt handler
- *          processes these operations. For the current implementation, there will be one user for
- *          each interrupt level available to the application (APP_HIGH, APP_LOW and THREAD_MODE),
- *          but the module can easily be modified to e.g. have one queue per process when using an
- *          RTOS. The purpose of the queues is to be able to have a completely lockless timer
- *          implementation.
- */
-typedef struct
-{
-    uint8_t           first;                                                    /**< Index of first entry to have been inserted in the queue (i.e. the next entry to be executed). */
-    uint8_t           last;                                                     /**< Index of last entry to have been inserted in the queue. */
-    uint8_t           user_op_queue_size;                                       /**< Queue size. */
-    timer_user_op_t * p_user_op_queue;                                          /**< Queue buffer. */
-} timer_user_t;
-
-STATIC_ASSERT(sizeof(timer_user_t) == APP_TIMER_USER_SIZE);
-STATIC_ASSERT(sizeof(timer_user_t) % 4 == 0);
-
-/**@brief User id type.
- *
- * @details In the current implementation, this will automatically be generated from the current
- *          interrupt level.
- */
-typedef uint32_t timer_user_id_t;
-
-#define CONTEXT_QUEUE_SIZE_MAX      (2)                 
-
-static uint8_t                       m_user_array_size;                         /**< Size of timer user array. */
-static timer_user_t *                mp_users = NULL;                           /**< Array of timer users. */
-static timer_node_t *                mp_timer_id_head;                          /**< First timer in list of running timers. */
-static uint32_t                      m_ticks_latest;                            /**< Last known RTC counter value. */
-static uint32_t                      m_ticks_elapsed[CONTEXT_QUEUE_SIZE_MAX];   /**< Timer internal elapsed ticks queue. */
-static uint8_t                       m_ticks_elapsed_q_read_ind;                /**< Timer internal elapsed ticks queue read index. */
-static uint8_t                       m_ticks_elapsed_q_write_ind;               /**< Timer internal elapsed ticks queue write index. */
-static app_timer_evt_schedule_func_t m_evt_schedule_func;                       /**< Pointer to function for propagating timeout events to the scheduler. */
-static bool                          m_rtc1_running;                            /**< Boolean indicating if RTC1 is running. */
-static bool                          m_rtc1_reset;                              /**< Boolean indicating if RTC1 counter has been reset due to last timer removed from timer list during the timer list handling. */
-
-#ifdef APP_TIMER_WITH_PROFILER
-static uint8_t                      m_max_user_op_queue_utilization;                  /**< Maximum observed timer user operations queue utilization. */
-#endif
-
-#define MODULE_INITIALIZED (mp_users != NULL)
-#include "sdk_macros.h"
-
-/**@brief Function for initializing the RTC1 counter.
- *
- * @param[in] prescaler   Value of the RTC1 PRESCALER register. Set to 0 for no prescaling.
- */
-static void rtc1_init(uint32_t prescaler)
-{
-    NRF_RTC1->PRESCALER = prescaler;
-    NVIC_SetPriority(RTC1_IRQn, RTC1_IRQ_PRI);
-}
-
-
-/**@brief Function for starting the RTC1 timer.
- */
-static void rtc1_start(void)
-{
-    NRF_RTC1->EVTENSET = RTC_EVTEN_COMPARE0_Msk;
-    NRF_RTC1->INTENSET = RTC_INTENSET_COMPARE0_Msk;
-
-    NVIC_ClearPendingIRQ(RTC1_IRQn);
-    NVIC_EnableIRQ(RTC1_IRQn);
-
-    NRF_RTC1->TASKS_START = 1;
-    nrf_delay_us(MAX_RTC_TASKS_DELAY);
-
-    m_rtc1_running = true;
-}
-
-
-/**@brief Function for stopping the RTC1 timer.
- */
-static void rtc1_stop(void)
-{
-    NVIC_DisableIRQ(RTC1_IRQn);
-
-    NRF_RTC1->EVTENCLR = RTC_EVTEN_COMPARE0_Msk;
-    NRF_RTC1->INTENCLR = RTC_INTENSET_COMPARE0_Msk;
-
-    NRF_RTC1->TASKS_STOP = 1;
-    nrf_delay_us(MAX_RTC_TASKS_DELAY);
-
-    NRF_RTC1->TASKS_CLEAR = 1;
-    m_ticks_latest        = 0;
-    nrf_delay_us(MAX_RTC_TASKS_DELAY);
-
-    m_rtc1_running = false;
-}
-
-
-/**@brief Function for returning the current value of the RTC1 counter.
- *
- * @return     Current value of the RTC1 counter.
- */
-static __INLINE uint32_t rtc1_counter_get(void)
-{
-    return NRF_RTC1->COUNTER;
-}
-
-
-/**@brief Function for computing the difference between two RTC1 counter values.
- *
- * @return     Number of ticks elapsed from ticks_old to ticks_now.
- */
-static __INLINE uint32_t ticks_diff_get(uint32_t ticks_now, uint32_t ticks_old)
-{
-    return ((ticks_now - ticks_old) & MAX_RTC_COUNTER_VAL);
-}
-
-
-/**@brief Function for setting the RTC1 Capture Compare register 0, and enabling the corresponding
- *        event.
- *
- * @param[in] value   New value of Capture Compare register 0.
- */
-static __INLINE void rtc1_compare0_set(uint32_t value)
-{
-    NRF_RTC1->CC[0] = value;
-}
-
-
-/**@brief Function for inserting a timer in the timer list.
- *
- * @param[in]  timer_id   Id of timer to insert.
- */
-static void timer_list_insert(timer_node_t * p_timer)
-{
-    if (mp_timer_id_head == NULL)
-    {
-        mp_timer_id_head = p_timer;
-    }
-    else
-    {
-        if (p_timer->ticks_to_expire <= mp_timer_id_head->ticks_to_expire)
-        {
-            mp_timer_id_head->ticks_to_expire -= p_timer->ticks_to_expire;
-            
-            p_timer->next   = mp_timer_id_head;
-            mp_timer_id_head = p_timer;
-        }
-        else
-        {
-            timer_node_t * p_previous;
-            timer_node_t * p_current;
-            uint32_t       ticks_to_expire;
-
-            ticks_to_expire   = p_timer->ticks_to_expire;
-            p_previous        = mp_timer_id_head;
-            p_current         = mp_timer_id_head;
-            
-            while ((p_current != NULL) && (ticks_to_expire > p_current->ticks_to_expire))
-            {
-                ticks_to_expire   -= p_current->ticks_to_expire;
-                p_previous         = p_current;
-                p_current          = p_current->next;
-            }
-
-            if (p_current != NULL)
-            {
-                p_current->ticks_to_expire -= ticks_to_expire;
-            }
-
-            p_timer->ticks_to_expire = ticks_to_expire;
-            p_timer->next            = p_current;
-            p_previous->next         = p_timer;
-        }
-    }
-}
-
-
-/**@brief Function for removing a timer from the timer queue.
- *
- * @param[in]  timer_id   Id of timer to remove.
- */
-static void timer_list_remove(timer_node_t * p_timer)
-{
-    timer_node_t * p_previous;
-    timer_node_t * p_current;
-    uint32_t       timeout;
-
-    // Find the timer's position in timer list.
-    p_previous = mp_timer_id_head;
-    p_current  = p_previous;
-    
-    while (p_current != NULL)
-    {
-        if (p_current == p_timer)
-        {
-            break;
-        }
-        p_previous = p_current;
-        p_current  = p_current->next;
-    }
-
-    // Timer not in active list.
-    if (p_current == NULL)
-    {
-        return;
-    }
-
-    // Timer is the first in the list
-    if (p_previous == p_current)
-    {
-        mp_timer_id_head = mp_timer_id_head->next;
-
-        // No more timers in the list. Reset RTC1 in case Start timer operations are present in the queue.
-        if (mp_timer_id_head == NULL)
-        {
-            NRF_RTC1->TASKS_CLEAR = 1;
-            m_ticks_latest        = 0;
-            m_rtc1_reset          = true;
-        }
-    }
-
-    // Remaining timeout between next timeout.
-    timeout = p_current->ticks_to_expire;
-
-    // Link previous timer with next of this timer, i.e. removing the timer from list.
-    p_previous->next = p_current->next;
-
-    // If this is not the last timer, increment the next timer by this timer timeout.
-    p_current = p_previous->next;
-    if (p_current != NULL)
-    {
-        p_current->ticks_to_expire += timeout;
-    }
-}
-
-
-/**@brief Function for scheduling a check for timeouts by generating a RTC1 interrupt.
- */
-static void timer_timeouts_check_sched(void)
-{
-    NVIC_SetPendingIRQ(RTC1_IRQn);
-}
-
-
-/**@brief Function for scheduling a timer list update by generating a SWI interrupt.
- */
-static void timer_list_handler_sched(void)
-{
-    NVIC_SetPendingIRQ(SWI_IRQn);
-}
-
-
-/**@brief Function for executing an application timeout handler, either by calling it directly, or
- *        by passing an event to the @ref app_scheduler.
- *
- * @param[in]  p_timer   Pointer to expired timer.
- */
-static void timeout_handler_exec(timer_node_t * p_timer)
-{
-    if (m_evt_schedule_func != NULL)
-    {
-        uint32_t err_code = m_evt_schedule_func(p_timer->p_timeout_handler, p_timer->p_context);
-        APP_ERROR_CHECK(err_code);
-    }
-    else
-    {
-        p_timer->p_timeout_handler(p_timer->p_context);
-    }
-}
-
-
-/**@brief Function for checking for expired timers.
- */
-static void timer_timeouts_check(void)
-{
-    // Handle expired of timer 
-    if (mp_timer_id_head != NULL)
-    {
-        timer_node_t *  p_timer;
-        timer_node_t *  p_previous_timer;
-        uint32_t        ticks_elapsed;
-        uint32_t        ticks_expired;
-
-        // Initialize actual elapsed ticks being consumed to 0.
-        ticks_expired = 0;
-
-        // ticks_elapsed is collected here, job will use it.
-        ticks_elapsed = ticks_diff_get(rtc1_counter_get(), m_ticks_latest);
-
-        // Auto variable containing the head of timers expiring.
-        p_timer = mp_timer_id_head;
-
-        // Expire all timers within ticks_elapsed and collect ticks_expired.
-        while (p_timer != NULL)
-        {
-            // Do nothing if timer did not expire.
-            if (ticks_elapsed < p_timer->ticks_to_expire)
-            {
-                break;
-            }
-
-            // Decrement ticks_elapsed and collect expired ticks.
-            ticks_elapsed -= p_timer->ticks_to_expire;
-            ticks_expired += p_timer->ticks_to_expire;
-
-            // Move to next timer.
-            p_previous_timer = p_timer;
-            p_timer = p_timer->next;
-
-            // Execute Task.
-            if (p_previous_timer->is_running)
-            {
-                p_previous_timer->is_running = false;
-                timeout_handler_exec(p_previous_timer);
-            }
-        }
-
-        // Prepare to queue the ticks expired in the m_ticks_elapsed queue.
-        if (m_ticks_elapsed_q_read_ind == m_ticks_elapsed_q_write_ind)
-        {
-            // The read index of the queue is equal to the write index. This means the new
-            // value of ticks_expired should be stored at a new location in the m_ticks_elapsed
-            // queue (which is implemented as a double buffer).
-
-            // Check if there will be a queue overflow.
-            if (++m_ticks_elapsed_q_write_ind == CONTEXT_QUEUE_SIZE_MAX)
-            {
-                // There will be a queue overflow. Hence the write index should point to the start
-                // of the queue.
-                m_ticks_elapsed_q_write_ind = 0;
-            }
-        }
-
-        // Queue the ticks expired.
-        m_ticks_elapsed[m_ticks_elapsed_q_write_ind] = ticks_expired;
-
-        timer_list_handler_sched();
-    }
-}
-
-
-/**@brief Function for acquiring the number of ticks elapsed.
- *
- * @param[out] p_ticks_elapsed   Number of ticks elapsed.
- *
- * @return     TRUE if elapsed ticks was read from queue, FALSE otherwise.
- */
-static bool elapsed_ticks_acquire(uint32_t * p_ticks_elapsed)
-{
-    // Pick the elapsed value from queue.
-    if (m_ticks_elapsed_q_read_ind != m_ticks_elapsed_q_write_ind)
-    {
-        // Dequeue elapsed value.
-        m_ticks_elapsed_q_read_ind++;
-        if (m_ticks_elapsed_q_read_ind == CONTEXT_QUEUE_SIZE_MAX)
-        {
-            m_ticks_elapsed_q_read_ind = 0;
-        }
-
-        *p_ticks_elapsed = m_ticks_elapsed[m_ticks_elapsed_q_read_ind];
-
-        m_ticks_latest += *p_ticks_elapsed;
-        m_ticks_latest &= MAX_RTC_COUNTER_VAL;
-
-        return true;
-    }
-    else
-    {
-        // No elapsed value in queue.
-        *p_ticks_elapsed = 0;
-        return false;
-    }
-}
-
-
-/**@brief Function for handling the timer list deletions.
- *
- * @return     TRUE if Capture Compare register must be updated, FALSE otherwise.
- */
-static bool list_deletions_handler(void)
-{
-    timer_node_t * p_timer_old_head;
-    uint8_t        user_id;
-
-    // Remember the old head, so as to decide if new compare needs to be set.
-    p_timer_old_head = mp_timer_id_head;
-
-    user_id = m_user_array_size;
-    while (user_id--)
-    {
-        timer_user_t * p_user         = &mp_users[user_id];
-        uint8_t        user_ops_first = p_user->first;
-        
-        while (user_ops_first != p_user->last)
-        {
-            timer_user_op_t * p_user_op = &p_user->p_user_op_queue[user_ops_first];
-
-            // Traverse to next operation in queue.
-            user_ops_first++;
-            if (user_ops_first == p_user->user_op_queue_size)
-            {
-                user_ops_first = 0;
-            }
-
-            switch (p_user_op->op_type)
-            {
-                case TIMER_USER_OP_TYPE_STOP:
-                    // Delete node if timer is running.
-                    timer_list_remove(p_user_op->p_node);
-                    break;
-                    
-                case TIMER_USER_OP_TYPE_STOP_ALL:
-                    // Delete list of running timers, and mark all timers as not running.
-                    while (mp_timer_id_head != NULL)
-                    {
-                        timer_node_t * p_head = mp_timer_id_head;
-
-                        p_head->is_running = false;
-                        mp_timer_id_head    = p_head->next;
-                    }
-                    break;
-                    
-                default:
-                    // No implementation needed.
-                    break;
-            }
-        }
-    }
-
-    // Detect change in head of the list.
-    return (mp_timer_id_head != p_timer_old_head);
-}
-
-
-/**@brief Function for updating the timer list for expired timers.
- *
- * @param[in]  ticks_elapsed         Number of elapsed ticks.
- * @param[in]  ticks_previous        Previous known value of the RTC counter.
- * @param[out] p_restart_list_head   List of repeating timers to be restarted.
- */
-static void expired_timers_handler(uint32_t         ticks_elapsed,
-                                   uint32_t         ticks_previous,
-                                   timer_node_t **  p_restart_list_head)
-{
-    uint32_t ticks_expired = 0;
-
-    while (mp_timer_id_head != NULL)
-    {
-        timer_node_t * p_timer;
-        timer_node_t * p_timer_expired;
-
-        // Auto variable for current timer node.
-        p_timer = mp_timer_id_head;
-
-        // Do nothing if timer did not expire 
-        if (ticks_elapsed < p_timer->ticks_to_expire)
-        {
-            p_timer->ticks_to_expire -= ticks_elapsed;
-            break;
-        }
-
-        // Decrement ticks_elapsed and collect expired ticks.
-        ticks_elapsed -= p_timer->ticks_to_expire;
-        ticks_expired += p_timer->ticks_to_expire;
-
-        // Timer expired, set ticks_to_expire zero.
-        p_timer->ticks_to_expire = 0;
-
-        // Remove the expired timer from head.
-        p_timer_expired  = mp_timer_id_head;
-        mp_timer_id_head = p_timer->next;
-
-        // Timer will be restarted if periodic.
-        if (p_timer->ticks_periodic_interval != 0)
-        {
-            p_timer->ticks_at_start       = (ticks_previous + ticks_expired) & MAX_RTC_COUNTER_VAL;
-            p_timer->ticks_first_interval = p_timer->ticks_periodic_interval;
-            p_timer->next                 = *p_restart_list_head;
-            *p_restart_list_head          = p_timer_expired;
-        }
-    }
-}
-
-
-/**@brief Function for handling timer list insertions.
- *
- * @param[in]  p_restart_list_head   List of repeating timers to be restarted.
- *
- * @return     TRUE if Capture Compare register must be updated, FALSE otherwise.
- */
-static bool list_insertions_handler(timer_node_t * p_restart_list_head)
-{
-    timer_node_t * p_timer_id_old_head;
-    uint8_t        user_id;
-
-    // Remember the old head, so as to decide if new compare needs to be set.
-    p_timer_id_old_head = mp_timer_id_head;
-
-    user_id = m_user_array_size;
-    while (user_id--)
-    {
-        timer_user_t * p_user = &mp_users[user_id];
-
-        // Handle insertions of timers.
-        while ((p_restart_list_head != NULL) || (p_user->first != p_user->last))
-        {
-            timer_node_t * p_timer;
-
-            if (p_restart_list_head != NULL)
-            {
-                p_timer           = p_restart_list_head;
-                p_restart_list_head = p_timer->next;
-            }
-            else
-            {
-                timer_user_op_t * p_user_op = &p_user->p_user_op_queue[p_user->first];
-
-                p_user->first++;
-                if (p_user->first == p_user->user_op_queue_size)
-                {
-                    p_user->first = 0;
-                }
-
-                p_timer = p_user_op->p_node;
-
-                if ((p_user_op->op_type != TIMER_USER_OP_TYPE_START) || p_timer->is_running)
-                {
-                    continue;
-                }
-
-                p_timer->ticks_at_start          = p_user_op->params.start.ticks_at_start;
-                p_timer->ticks_first_interval    = p_user_op->params.start.ticks_first_interval;
-                p_timer->ticks_periodic_interval = p_user_op->params.start.ticks_periodic_interval;
-                p_timer->p_context               = p_user_op->params.start.p_context;
-
-                if (m_rtc1_reset)
-                {
-                    p_timer->ticks_at_start = 0;
-                }
-            }
-
-            // Prepare the node to be inserted.
-            if (
-                 ((p_timer->ticks_at_start - m_ticks_latest) & MAX_RTC_COUNTER_VAL)
-                 <
-                 (MAX_RTC_COUNTER_VAL / 2)
-                )
-            {
-                p_timer->ticks_to_expire = ticks_diff_get(p_timer->ticks_at_start, m_ticks_latest) + 
-                                           p_timer->ticks_first_interval;
-            }
-            else
-            {
-                uint32_t delta_current_start;
-
-                delta_current_start = ticks_diff_get(m_ticks_latest, p_timer->ticks_at_start);
-                if (p_timer->ticks_first_interval > delta_current_start)
-                {
-                    p_timer->ticks_to_expire = p_timer->ticks_first_interval - delta_current_start;
-                }
-                else
-                {
-                    p_timer->ticks_to_expire = 0;
-                }
-            }
-
-            p_timer->ticks_at_start       = 0;
-            p_timer->ticks_first_interval = 0;
-            p_timer->is_running           = true;
-            p_timer->next                 = NULL;
-
-            // Insert into list 
-            timer_list_insert(p_timer);
-        }
-    }
-    
-    return (mp_timer_id_head != p_timer_id_old_head);
-}
-
-
-/**@brief Function for updating the Capture Compare register.
- */
-static void compare_reg_update(timer_node_t * p_timer_id_head_old)
-{
-    // Setup the timeout for timers on the head of the list 
-    if (mp_timer_id_head != NULL)
-    {
-        uint32_t ticks_to_expire = mp_timer_id_head->ticks_to_expire;
-        uint32_t pre_counter_val = rtc1_counter_get();
-        uint32_t cc              = m_ticks_latest;
-        uint32_t ticks_elapsed   = ticks_diff_get(pre_counter_val, cc) + RTC_COMPARE_OFFSET_MIN;
-
-        if (!m_rtc1_running)
-        {
-            // No timers were already running, start RTC
-            rtc1_start();
-        }
-
-        cc += (ticks_elapsed < ticks_to_expire) ? ticks_to_expire : ticks_elapsed;
-        cc &= MAX_RTC_COUNTER_VAL;
-        
-        rtc1_compare0_set(cc);
-
-        uint32_t post_counter_val = rtc1_counter_get();
-
-        if (
-            (ticks_diff_get(post_counter_val, pre_counter_val) + RTC_COMPARE_OFFSET_MIN)
-            >
-            ticks_diff_get(cc, pre_counter_val)
-           )
-        {
-            // When this happens the COMPARE event may not be triggered by the RTC.
-            // The nRF51 Series User Specification states that if the COUNTER value is N
-            // (i.e post_counter_val = N), writing N or N+1 to a CC register may not trigger a
-            // COMPARE event. Hence the RTC interrupt is forcefully pended by calling the following
-            // function.
-            rtc1_compare0_set(rtc1_counter_get());  // this should prevent CC to fire again in the background while the code is in RTC-ISR
-            nrf_delay_us(MAX_RTC_TASKS_DELAY);
-            timer_timeouts_check_sched();
-        }
-    }
-    else
-    {
-        // No timers are running, stop RTC
-        rtc1_stop();
-    }
-}
-
-
-/**@brief Function for handling changes to the timer list.
- */
-static void timer_list_handler(void)
-{
-    timer_node_t * p_restart_list_head = NULL;
-
-    uint32_t       ticks_elapsed;
-    uint32_t       ticks_previous;
-    bool           ticks_have_elapsed;
-    bool           compare_update;
-    timer_node_t * p_timer_id_head_old;
-    
-#ifdef APP_TIMER_WITH_PROFILER
-    {
-        unsigned int i;
-
-        for (i = 0; i < APP_TIMER_INT_LEVELS; i++)
-        {
-            timer_user_t *p_user = &mp_users[i];
-            uint8_t size = p_user->user_op_queue_size;
-            uint8_t first = p_user->first;
-            uint8_t last = p_user->last;
-            uint8_t utilization = (first <= last) ? (last - first) : (size + 1 - first + last);
-
-            if (utilization > m_max_user_op_queue_utilization)
-            {
-                m_max_user_op_queue_utilization = utilization;
-            }
-        }
-    }
-#endif
-
-    // Back up the previous known tick and previous list head
-    ticks_previous    = m_ticks_latest;
-    p_timer_id_head_old = mp_timer_id_head;
-    
-    // Get number of elapsed ticks
-    ticks_have_elapsed = elapsed_ticks_acquire(&ticks_elapsed);
-
-    // Handle list deletions
-    compare_update = list_deletions_handler();
-    
-    // Handle expired timers
-    if (ticks_have_elapsed)
-    {
-        expired_timers_handler(ticks_elapsed, ticks_previous, &p_restart_list_head);
-        compare_update = true;
-    }
-    
-    // Handle list insertions
-    if (list_insertions_handler(p_restart_list_head))
-    {
-        compare_update = true;
-    }
-
-    // Update compare register if necessary
-    if (compare_update)
-    {
-        compare_reg_update(p_timer_id_head_old);
-    }
-    m_rtc1_reset = false;
-}
-
-
-/**@brief Function for enqueueing a new operations queue entry.
- *
- * @param[in]  p_user     User that the entry is to be enqueued for.
- * @param[in]  last_index Index of the next last index to be enqueued.
- */
-static void user_op_enque(timer_user_t * p_user, uint8_t last_index)
-{
-    p_user->last = last_index;
-}
-
-
-/**@brief Function for allocating a new operations queue entry.
- *
- * @param[in]  p_user       User that the entry is to be allocated for.
- * @param[out] p_last_index Index of the next last index to be enqueued.
- *
- * @return     Pointer to allocated queue entry, or NULL if queue is full.
- */
-static timer_user_op_t * user_op_alloc(timer_user_t * p_user, uint8_t * p_last_index)
-{        
-    uint8_t           last;
-    timer_user_op_t * p_user_op;
-    
-    last = p_user->last + 1;
-    if (last == p_user->user_op_queue_size)
-    {
-        // Overflow case.
-        last = 0;
-    }
-    if (last == p_user->first)
-    {
-        // Queue is full.
-        return NULL;
-    }
-    
-    *p_last_index = last;    
-    p_user_op     = &p_user->p_user_op_queue[p_user->last];
-        
-    return p_user_op;
-}
-
-
-/**@brief Function for scheduling a Timer Start operation.
- *
- * @param[in]  user_id           Id of user calling this function.
- * @param[in]  timer_id          Id of timer to start.
- * @param[in]  timeout_initial   Time (in ticks) to first timer expiry.
- * @param[in]  timeout_periodic  Time (in ticks) between periodic expiries.
- * @param[in]  p_context         General purpose pointer. Will be passed to the timeout handler when
- *                               the timer expires.
- * @return     NRF_SUCCESS on success, otherwise an error code.
- */
-static uint32_t timer_start_op_schedule(timer_user_id_t user_id,
-                                        timer_node_t * p_node,
-                                        uint32_t        timeout_initial,
-                                        uint32_t        timeout_periodic,
-                                        void *          p_context)
-{
-    uint8_t last_index;
-    
-    timer_user_op_t * p_user_op = user_op_alloc(&mp_users[user_id], &last_index);
-    if (p_user_op == NULL)
-    {
-        return NRF_ERROR_NO_MEM;
-    }
-    
-    p_user_op->op_type                              = TIMER_USER_OP_TYPE_START;
-    p_user_op->p_node                               = p_node;
-    p_user_op->params.start.ticks_at_start          = rtc1_counter_get();
-    p_user_op->params.start.ticks_first_interval    = timeout_initial;
-    p_user_op->params.start.ticks_periodic_interval = timeout_periodic;
-    p_user_op->params.start.p_context               = p_context;
-    
-    user_op_enque(&mp_users[user_id], last_index);    
-
-    timer_list_handler_sched();
-
-    return NRF_SUCCESS;
-}
-
-
-/**@brief Function for scheduling a Timer Stop operation.
- *
- * @param[in]  user_id    Id of user calling this function.
- * @param[in]  timer_id   Id of timer to stop.
- *
- * @return NRF_SUCCESS on successful scheduling a timer stop operation. NRF_ERROR_NO_MEM when there
- *         is no memory left to schedule the timer stop operation.
- */
-static uint32_t timer_stop_op_schedule(timer_user_id_t user_id, timer_node_t * p_node)
-{
-    uint8_t last_index;
-    
-    timer_user_op_t * p_user_op = user_op_alloc(&mp_users[user_id], &last_index);
-    if (p_user_op == NULL)
-    {
-        return NRF_ERROR_NO_MEM;
-    }
-    
-    p_user_op->op_type  = TIMER_USER_OP_TYPE_STOP;
-    p_user_op->p_node = p_node;
-    
-    user_op_enque(&mp_users[user_id], last_index);        
-
-    timer_list_handler_sched();
-
-    return NRF_SUCCESS;
-}
-
-
-/**@brief Function for scheduling a Timer Stop All operation.
- *
- * @param[in]  user_id    Id of user calling this function.
- */
-static uint32_t timer_stop_all_op_schedule(timer_user_id_t user_id)
-{
-    uint8_t last_index;
-    
-    timer_user_op_t * p_user_op = user_op_alloc(&mp_users[user_id], &last_index);
-    if (p_user_op == NULL)
-    {
-        return NRF_ERROR_NO_MEM;
-    }
-    
-    p_user_op->op_type  = TIMER_USER_OP_TYPE_STOP_ALL;
-    p_user_op->p_node = NULL;
-    
-    user_op_enque(&mp_users[user_id], last_index);        
-
-    timer_list_handler_sched();
-
-    return NRF_SUCCESS;
-}
-
-
-/**@brief Function for handling the RTC1 interrupt.
- *
- * @details Checks for timeouts, and executes timeout handlers for expired timers.
- */
-void RTC1_IRQHandler(void)
-{
-    // Clear all events (also unexpected ones)
-    NRF_RTC1->EVENTS_COMPARE[0] = 0;
-    NRF_RTC1->EVENTS_COMPARE[1] = 0;
-    NRF_RTC1->EVENTS_COMPARE[2] = 0;
-    NRF_RTC1->EVENTS_COMPARE[3] = 0;
-    NRF_RTC1->EVENTS_TICK       = 0;
-    NRF_RTC1->EVENTS_OVRFLW     = 0;
-
-    // Check for expired timers
-    timer_timeouts_check();
-}
-
-
-/**@brief Function for handling the SWI interrupt.
- *
- * @details Performs all updates to the timer list.
- */
-void SWI_IRQHandler(void)
-{
-    timer_list_handler();
-}
-
-
-uint32_t app_timer_init(uint32_t                      prescaler,
-                        uint8_t                       op_queues_size,
-                        void *                        p_buffer,
-                        app_timer_evt_schedule_func_t evt_schedule_func)
-{
-    int i;
-
-    // Check that buffer is correctly aligned
-    if (!is_word_aligned(p_buffer))
-    {
-        return NRF_ERROR_INVALID_PARAM;
-    }
-    // Check for NULL buffer
-    if (p_buffer == NULL)
-    {
-        mp_users = NULL;
-        return NRF_ERROR_INVALID_PARAM;
-    }
-    
-    // Stop RTC to prevent any running timers from expiring (in case of reinitialization)
-    rtc1_stop();
-    
-    m_evt_schedule_func = evt_schedule_func;
-    
-    // Initialize users array
-    m_user_array_size = APP_TIMER_INT_LEVELS;
-    mp_users          = p_buffer;
-    
-    // Skip user array
-    p_buffer = &((uint8_t *)p_buffer)[APP_TIMER_INT_LEVELS * sizeof(timer_user_t)];
-
-    // Initialize operation queues
-    for (i = 0; i < APP_TIMER_INT_LEVELS; i++)
-    {
-        timer_user_t * p_user = &mp_users[i];
-        
-        p_user->first              = 0;
-        p_user->last               = 0;
-        p_user->user_op_queue_size = op_queues_size;
-        p_user->p_user_op_queue    = p_buffer;
-    
-        // Skip operation queue
-        p_buffer = &((uint8_t *)p_buffer)[op_queues_size * sizeof(timer_user_op_t)];
-    }
-
-    mp_timer_id_head             = NULL;
-    m_ticks_elapsed_q_read_ind  = 0;
-    m_ticks_elapsed_q_write_ind = 0;
-
-#ifdef APP_TIMER_WITH_PROFILER
-    m_max_user_op_queue_utilization   = 0;
-#endif
-
-    NVIC_ClearPendingIRQ(SWI_IRQn);
-    NVIC_SetPriority(SWI_IRQn, SWI_IRQ_PRI);
-    NVIC_EnableIRQ(SWI_IRQn);
-
-    rtc1_init(prescaler);
-
-    m_ticks_latest = rtc1_counter_get();
-    
-    return NRF_SUCCESS;
-}
-
-
-uint32_t app_timer_create(app_timer_id_t const *      p_timer_id,
-                          app_timer_mode_t            mode,
-                          app_timer_timeout_handler_t timeout_handler)
-{
-    // Check state and parameters
-    VERIFY_MODULE_INITIALIZED();
-
-    if (timeout_handler == NULL)
-    {
-        return NRF_ERROR_INVALID_PARAM;
-    }
-    if (p_timer_id == NULL)
-    {
-        return NRF_ERROR_INVALID_PARAM;
-    }
-    if (((timer_node_t*)*p_timer_id)->is_running)
-    {
-        return NRF_ERROR_INVALID_STATE;
-    }
-    
-    timer_node_t * p_node     = (timer_node_t *)*p_timer_id;
-    p_node->is_running        = false;
-    p_node->mode              = mode;
-    p_node->p_timeout_handler = timeout_handler;
-    return NRF_SUCCESS;
-}
-
-
-/**@brief Function for creating a timer user id from the current interrupt level.
- *
- * @return     Timer user id.
-*/
-static timer_user_id_t user_id_get(void)
-{
-    timer_user_id_t ret;
-
-    STATIC_ASSERT(APP_TIMER_INT_LEVELS == 3);
-    
-    switch (current_int_priority_get())
-    {
-        case APP_IRQ_PRIORITY_HIGH:
-            ret = APP_HIGH_USER_ID;
-            break;
-            
-        case APP_IRQ_PRIORITY_LOW:
-            ret = APP_LOW_USER_ID;
-            break;
-            
-        default:
-            ret = THREAD_MODE_USER_ID;
-            break;
-    }
-    
-    return ret;
-}
-
-
-uint32_t app_timer_start(app_timer_id_t timer_id, uint32_t timeout_ticks, void * p_context)
-{
-    uint32_t timeout_periodic;
-    timer_node_t * p_node = (timer_node_t*)timer_id;
-    
-    // Check state and parameters
-    VERIFY_MODULE_INITIALIZED();
-
-    if (timer_id == 0)
-    {
-        return NRF_ERROR_INVALID_STATE;
-    }
-    if (timeout_ticks < APP_TIMER_MIN_TIMEOUT_TICKS)
-    {
-        return NRF_ERROR_INVALID_PARAM;
-    }
-    if (p_node->p_timeout_handler == NULL)
-    {
-        return NRF_ERROR_INVALID_STATE;
-    }
-    
-    // Schedule timer start operation
-    timeout_periodic = (p_node->mode == APP_TIMER_MODE_REPEATED) ? timeout_ticks : 0;
-
-    return timer_start_op_schedule(user_id_get(),
-                                   p_node,
-                                   timeout_ticks,
-                                   timeout_periodic,
-                                   p_context);
-}
-
-
-uint32_t app_timer_stop(app_timer_id_t timer_id)
-{
-    timer_node_t * p_node = (timer_node_t*)timer_id;
-    // Check state and parameters
-    VERIFY_MODULE_INITIALIZED();
-
-    if ((timer_id == NULL) || (p_node->p_timeout_handler == NULL))
-    {
-        return NRF_ERROR_INVALID_STATE;
-    }
-    
-    p_node->is_running = false;
-    // Schedule timer stop operation
-    return timer_stop_op_schedule(user_id_get(), p_node);
-}
-
-
-uint32_t app_timer_stop_all(void)
-{
-    // Check state
-    VERIFY_MODULE_INITIALIZED();
-
-    return timer_stop_all_op_schedule(user_id_get());
-}
-
-
-uint32_t app_timer_cnt_get(uint32_t * p_ticks)
-{
-    *p_ticks = rtc1_counter_get();
-    return NRF_SUCCESS;
-}
-
-
-uint32_t app_timer_cnt_diff_compute(uint32_t   ticks_to,
-                                    uint32_t   ticks_from,
-                                    uint32_t * p_ticks_diff)
-{
-    *p_ticks_diff = ticks_diff_get(ticks_to, ticks_from);
-    return NRF_SUCCESS;
-}
-
-#ifdef APP_TIMER_WITH_PROFILER
-uint8_t app_timer_op_queue_utilization_get(void)
-{
-    return m_max_user_op_queue_utilization;
-}
-#endif

http://git-wip-us.apache.org/repos/asf/incubator-mynewt-core/blob/a1481cb2/hw/mcu/nordic/src/ext/nRF5_SDK_11.0.0_89a8197/components/libraries/timer/app_timer.h
----------------------------------------------------------------------
diff --git a/hw/mcu/nordic/src/ext/nRF5_SDK_11.0.0_89a8197/components/libraries/timer/app_timer.h b/hw/mcu/nordic/src/ext/nRF5_SDK_11.0.0_89a8197/components/libraries/timer/app_timer.h
deleted file mode 100644
index 37393eb..0000000
--- a/hw/mcu/nordic/src/ext/nRF5_SDK_11.0.0_89a8197/components/libraries/timer/app_timer.h
+++ /dev/null
@@ -1,295 +0,0 @@
-/* Copyright (c) 2012 Nordic Semiconductor. All Rights Reserved.
- *
- * The information contained herein is property of Nordic Semiconductor ASA.
- * Terms and conditions of usage are described in detail in NORDIC
- * SEMICONDUCTOR STANDARD SOFTWARE LICENSE AGREEMENT.
- *
- * Licensees are granted free, non-transferable use of the information. NO
- * WARRANTY of ANY KIND is provided. This heading must NOT be removed from
- * the file.
- *
- */
-
-/** @file
- *
- * @defgroup app_timer Application Timer
- * @{
- * @ingroup app_common
- *
- * @brief Application timer functionality.
- *
- * @details This module enables the application to create multiple timer instances based on the RTC1
- *          peripheral. Checking for time-outs and invokation of user time-out handlers is performed
- *          in the RTC1 interrupt handler. List handling is done using a software interrupt (SWI0).
- *          Both interrupt handlers are running in APP_LOW priority level.
- *
- * @details When calling app_timer_start() or app_timer_stop(), the timer operation is just queued,
- *          and the software interrupt is triggered. The actual timer start/stop operation is
- *          executed by the SWI0 interrupt handler. Since the SWI0 interrupt is running in APP_LOW,
- *          if the application code calling the timer function is running in APP_LOW or APP_HIGH,
- *          the timer operation will not be performed until the application handler has returned.
- *          This will be the case, for example, when stopping a timer from a time-out handler when not using
- *          the scheduler.
- *
- * @details Use the USE_SCHEDULER parameter of the APP_TIMER_INIT() macro to select if the
- *          @ref app_scheduler should be used or not. Even if the scheduler is 
- *          not used, app_timer.h will include app_scheduler.h, so when
- *          compiling, app_scheduler.h must be available in one of the compiler include paths.
- */
-
-#ifndef APP_TIMER_H__
-#define APP_TIMER_H__
-
-#include <stdint.h>
-#include <stdbool.h>
-#include <stdio.h>
-#include "app_error.h"
-#include "app_util.h"
-#include "compiler_abstraction.h"
-
-#ifdef __cplusplus
-extern "C" {
-#endif
-
-#define APP_TIMER_CLOCK_FREQ         32768                      /**< Clock frequency of the RTC timer used to implement the app timer module. */
-#define APP_TIMER_MIN_TIMEOUT_TICKS  5                          /**< Minimum value of the timeout_ticks parameter of app_timer_start(). */
-
-#define APP_TIMER_NODE_SIZE          32                         /**< Size of app_timer.timer_node_t (used to allocate data). */
-#define APP_TIMER_USER_OP_SIZE       24                         /**< Size of app_timer.timer_user_op_t (only for use inside APP_TIMER_BUF_SIZE()). */
-#define APP_TIMER_USER_SIZE          8                          /**< Size of app_timer.timer_user_t (only for use inside APP_TIMER_BUF_SIZE()). */
-#define APP_TIMER_INT_LEVELS         3                          /**< Number of interrupt levels from where timer operations may be initiated (only for use inside APP_TIMER_BUF_SIZE()). */
-
-/**@brief Compute number of bytes required to hold the application timer data structures.
- *
- * @param[in]  OP_QUEUE_SIZE   Size of queues holding timer operations that are pending execution.
- *                             Note that due to the queue implementation, this size must be one more
- *                             than the size that is actually needed.
- *
- * @return     Required application timer buffer size (in bytes).
- */
-#define APP_TIMER_BUF_SIZE(OP_QUEUE_SIZE)                                              \
-    (                                                                                              \
-        (                                                                                          \
-            APP_TIMER_INT_LEVELS                                                                   \
-            *                                                                                      \
-            (APP_TIMER_USER_SIZE + ((OP_QUEUE_SIZE) + 1) * APP_TIMER_USER_OP_SIZE)                 \
-        )                                                                                          \
-    )
-
-/**@brief Convert milliseconds to timer ticks.
- *
- * This macro uses 64-bit integer arithmetic, but as long as the macro parameters are
- *       constants (i.e. defines), the computation will be done by the preprocessor.
- * 
- * When using this macro, ensure that the 
- *         values provided as input result in an output value that is supported by the
- *         @ref app_timer_start function. For example, when the ticks for 1 ms is needed, the
- *         maximum possible value of PRESCALER must be 6, when @ref APP_TIMER_CLOCK_FREQ is 32768.
- *         This will result in a ticks value as 5. Any higher value for PRESCALER will result in a
- *         ticks value that is not supported by this module.
- *
- * @param[in]  MS          Milliseconds.
- * @param[in]  PRESCALER   Value of the RTC1 PRESCALER register (must be the same value that was
- *                         passed to APP_TIMER_INIT()). 
- *
- * @return     Number of timer ticks.
- */
-#define APP_TIMER_TICKS(MS, PRESCALER)\
-            ((uint32_t)ROUNDED_DIV((MS) * (uint64_t)APP_TIMER_CLOCK_FREQ, ((PRESCALER) + 1) * 1000))
-
-typedef struct app_timer_t { uint32_t data[CEIL_DIV(APP_TIMER_NODE_SIZE, sizeof(uint32_t))]; } app_timer_t;
-
-/**@brief Timer ID type.
- * Never declare a variable of this type, but use the macro @ref APP_TIMER_DEF instead.*/
-typedef app_timer_t * app_timer_id_t;
-
-/**
- * @brief Create a timer identifier and statically allocate memory for the timer.
- *
- * @param timer_id Name of the timer identifier variable that will be used to control the timer.
- */
-#define APP_TIMER_DEF(timer_id)                                  \
-    static app_timer_t timer_id##_data = { {0} };                  \
-    static const app_timer_id_t timer_id = &timer_id##_data
-
-
-/**@brief Application time-out handler type. */
-typedef void (*app_timer_timeout_handler_t)(void * p_context);
-
-/**@brief Type of function for passing events from the timer module to the scheduler. */
-typedef uint32_t (*app_timer_evt_schedule_func_t) (app_timer_timeout_handler_t timeout_handler,
-                                                   void *                      p_context);
-
-/**@brief Timer modes. */
-typedef enum
-{
-    APP_TIMER_MODE_SINGLE_SHOT,                 /**< The timer will expire only once. */
-    APP_TIMER_MODE_REPEATED                     /**< The timer will restart each time it expires. */
-} app_timer_mode_t;
-
-/**@brief Initialize the application timer module.
- *
- * @details This macro handles dimensioning and allocation of the memory buffer required by the timer,
- *          making sure that the buffer is correctly aligned. It will also connect the timer module
- *          to the scheduler (if specified).
- *
- * @note    This module assumes that the LFCLK is already running. If it is not, the module will 
- *          be non-functional, since the RTC will not run. If you do not use a SoftDevice, you 
- *          must start the LFCLK manually. See the rtc_example's lfclk_config() function 
- *          for an example of how to do this. If you use a SoftDevice, the LFCLK is started on 
- *          SoftDevice init. 
- *
- *
- * @param[in]  PRESCALER        Value of the RTC1 PRESCALER register. This will decide the
- *                              timer tick rate. Set to 0 for no prescaling.
- * @param[in]  OP_QUEUES_SIZE   Size of queues holding timer operations that are pending execution.
- * @param[in]  SCHEDULER_FUNC   Pointer to scheduler event handler
- *
- * @note Since this macro allocates a buffer, it must only be called once (it is OK to call it
- *       several times as long as it is from the same location, for example, to do a re-initialization).
- */
-/*lint -emacro(506, APP_TIMER_INIT) */ /* Suppress "Constant value Boolean */
-#define APP_TIMER_INIT(PRESCALER, OP_QUEUES_SIZE, SCHEDULER_FUNC)                                  \
-    do                                                                                             \
-    {                                                                                              \
-        static uint32_t APP_TIMER_BUF[CEIL_DIV(APP_TIMER_BUF_SIZE((OP_QUEUES_SIZE) + 1),           \
-                                               sizeof(uint32_t))];                                 \
-        uint32_t ERR_CODE = app_timer_init((PRESCALER),                                            \
-                                           (OP_QUEUES_SIZE) + 1,                                   \
-                                           APP_TIMER_BUF,                                          \
-                                           SCHEDULER_FUNC);                                        \
-        APP_ERROR_CHECK(ERR_CODE);                                                                 \
-    } while (0)
-
-
-
-/**@brief Function for initializing the timer module.
- *
- * Normally, initialization should be done using the APP_TIMER_INIT() macro, because that macro will both
- *       allocate the buffers needed by the timer module (including aligning the buffers correctly)
- *       and take care of connecting the timer module to the scheduler (if specified).
- *
- * @param[in]  prescaler           Value of the RTC1 PRESCALER register. Set to 0 for no prescaling.
- * @param[in]  op_queues_size      Size of queues holding timer operations that are pending
- *                                 execution. Note that due to the queue implementation, this size must
- *                                 be one more than the size that is actually needed.
- * @param[in]  p_buffer            Pointer to memory buffer for internal use in the app_timer
- *                                 module. The size of the buffer can be computed using the
- *                                 APP_TIMER_BUF_SIZE() macro. The buffer must be aligned to a
- *                                 4 byte boundary.
- * @param[in]  evt_schedule_func   Function for passing time-out events to the scheduler. Point to
- *                                 app_timer_evt_schedule() to connect to the scheduler. Set to NULL
- *                                 to make the timer module call the time-out handler directly from
- *                                 the timer interrupt handler.
- *
- * @retval     NRF_SUCCESS               If the module was initialized successfully.
- * @retval     NRF_ERROR_INVALID_PARAM   If a parameter was invalid (buffer not aligned to a 4 byte
- *                                       boundary or NULL).
- */
-uint32_t app_timer_init(uint32_t                      prescaler, 
-                        uint8_t                       op_queues_size,
-                        void *                        p_buffer,
-                        app_timer_evt_schedule_func_t evt_schedule_func);
-
-/**@brief Function for creating a timer instance.
- *
- * @param[in]  p_timer_id        Pointer to timer identifier.
- * @param[in]  mode              Timer mode.
- * @param[in]  timeout_handler   Function to be executed when the timer expires.
- *
- * @retval     NRF_SUCCESS               If the timer was successfully created.
- * @retval     NRF_ERROR_INVALID_PARAM   If a parameter was invalid.
- * @retval     NRF_ERROR_INVALID_STATE   If the application timer module has not been initialized or
- *                                       the timer is running.
- *
- * @note This function does the timer allocation in the caller's context. It is also not protected
- *       by a critical region. Therefore care must be taken not to call it from several interrupt
- *       levels simultaneously.
- * @note The function can be called again on the timer instance and will re-initialize the instance if
- *       the timer is not running.
- * @attention The FreeRTOS and RTX app_timer implementation does not allow app_timer_create to
- *       be called on the previously initialized instance.
- */
-uint32_t app_timer_create(app_timer_id_t const *      p_timer_id,
-                          app_timer_mode_t            mode,
-                          app_timer_timeout_handler_t timeout_handler);
-
-/**@brief Function for starting a timer.
- *
- * @param[in]       timer_id      Timer identifier.
- * @param[in]       timeout_ticks Number of ticks (of RTC1, including prescaling) to time-out event
- *                                (minimum 5 ticks).
- * @param[in]       p_context     General purpose pointer. Will be passed to the time-out handler when
- *                                the timer expires.
- *
- * @retval     NRF_SUCCESS               If the timer was successfully started.
- * @retval     NRF_ERROR_INVALID_PARAM   If a parameter was invalid.
- * @retval     NRF_ERROR_INVALID_STATE   If the application timer module has not been initialized or the timer
- *                                       has not been created.
- * @retval     NRF_ERROR_NO_MEM          If the timer operations queue was full.
- *
- * @note The minimum timeout_ticks value is 5.
- * @note For multiple active timers, time-outs occurring in close proximity to each other (in the
- *       range of 1 to 3 ticks) will have a positive jitter of maximum 3 ticks.
- * @note When calling this method on a timer that is already running, the second start operation
- *       is ignored.
- */
-uint32_t app_timer_start(app_timer_id_t timer_id, uint32_t timeout_ticks, void * p_context);
-
-/**@brief Function for stopping the specified timer.
- *
- * @param[in]  timer_id                  Timer identifier.
- *
- * @retval     NRF_SUCCESS               If the timer was successfully stopped.
- * @retval     NRF_ERROR_INVALID_PARAM   If a parameter was invalid.
- * @retval     NRF_ERROR_INVALID_STATE   If the application timer module has not been initialized or the timer
- *                                       has not been created.
- * @retval     NRF_ERROR_NO_MEM          If the timer operations queue was full.
- */
-uint32_t app_timer_stop(app_timer_id_t timer_id);
-
-/**@brief Function for stopping all running timers.
- *
- * @retval     NRF_SUCCESS               If all timers were successfully stopped.
- * @retval     NRF_ERROR_INVALID_STATE   If the application timer module has not been initialized.
- * @retval     NRF_ERROR_NO_MEM          If the timer operations queue was full.
- */
-uint32_t app_timer_stop_all(void);
-
-/**@brief Function for returning the current value of the RTC1 counter.
- *
- * @param[out] p_ticks   Current value of the RTC1 counter.
- *
- * @retval     NRF_SUCCESS   If the counter was successfully read.
- */
-uint32_t app_timer_cnt_get(uint32_t * p_ticks);
-
-/**@brief Function for computing the difference between two RTC1 counter values.
- *
- * @param[in]  ticks_to       Value returned by app_timer_cnt_get().
- * @param[in]  ticks_from     Value returned by app_timer_cnt_get().
- * @param[out] p_ticks_diff   Number of ticks from ticks_from to ticks_to.
- *
- * @retval     NRF_SUCCESS   If the counter difference was successfully computed.
- */
-uint32_t app_timer_cnt_diff_compute(uint32_t   ticks_to,
-                                    uint32_t   ticks_from,
-                                    uint32_t * p_ticks_diff);
-
-#ifdef APP_TIMER_WITH_PROFILER
-/**@brief Function for getting the maximum observed operation queue utilization.
- *
- * Function for tuning the module and determining OP_QUEUE_SIZE value and thus module RAM usage.
- *
- * @return Maximum number of events in queue observed so far.
- */
-uint16_t app_timer_op_queue_utilization_get(void);
-#endif
-
-#ifdef __cplusplus
-}
-#endif
-
-#endif // APP_TIMER_H__
-
-/** @} */

http://git-wip-us.apache.org/repos/asf/incubator-mynewt-core/blob/a1481cb2/hw/mcu/nordic/src/ext/nRF5_SDK_11.0.0_89a8197/components/libraries/timer/app_timer_appsh.c
----------------------------------------------------------------------
diff --git a/hw/mcu/nordic/src/ext/nRF5_SDK_11.0.0_89a8197/components/libraries/timer/app_timer_appsh.c b/hw/mcu/nordic/src/ext/nRF5_SDK_11.0.0_89a8197/components/libraries/timer/app_timer_appsh.c
deleted file mode 100644
index 9755d78..0000000
--- a/hw/mcu/nordic/src/ext/nRF5_SDK_11.0.0_89a8197/components/libraries/timer/app_timer_appsh.c
+++ /dev/null
@@ -1,34 +0,0 @@
-/* Copyright (c) 2014 Nordic Semiconductor. All Rights Reserved.
- *
- * The information contained herein is property of Nordic Semiconductor ASA.
- * Terms and conditions of usage are described in detail in NORDIC
- * SEMICONDUCTOR STANDARD SOFTWARE LICENSE AGREEMENT.
- *
- * Licensees are granted free, non-transferable use of the information. NO
- * WARRANTY of ANY KIND is provided. This heading must NOT be removed from
- * the file.
- *
- */
-
-#include "app_timer_appsh.h"
-#include "app_scheduler.h"
-
-static void app_timer_evt_get(void * p_event_data, uint16_t event_size)
-{
-    app_timer_event_t * p_timer_event = (app_timer_event_t *)p_event_data;
-    
-    APP_ERROR_CHECK_BOOL(event_size == sizeof(app_timer_event_t));
-    p_timer_event->timeout_handler(p_timer_event->p_context);
-}
-
-uint32_t app_timer_evt_schedule(app_timer_timeout_handler_t timeout_handler,
-                                void *                      p_context)
-{
-    app_timer_event_t timer_event;
-
-    timer_event.timeout_handler = timeout_handler;
-    timer_event.p_context       = p_context;
-    
-    return app_sched_event_put(&timer_event, sizeof(timer_event), app_timer_evt_get);
-}
-

http://git-wip-us.apache.org/repos/asf/incubator-mynewt-core/blob/a1481cb2/hw/mcu/nordic/src/ext/nRF5_SDK_11.0.0_89a8197/components/libraries/timer/app_timer_appsh.h
----------------------------------------------------------------------
diff --git a/hw/mcu/nordic/src/ext/nRF5_SDK_11.0.0_89a8197/components/libraries/timer/app_timer_appsh.h b/hw/mcu/nordic/src/ext/nRF5_SDK_11.0.0_89a8197/components/libraries/timer/app_timer_appsh.h
deleted file mode 100644
index 77a5951..0000000
--- a/hw/mcu/nordic/src/ext/nRF5_SDK_11.0.0_89a8197/components/libraries/timer/app_timer_appsh.h
+++ /dev/null
@@ -1,52 +0,0 @@
-/* Copyright (c) 2014 Nordic Semiconductor. All Rights Reserved.
- *
- * The information contained herein is property of Nordic Semiconductor ASA.
- * Terms and conditions of usage are described in detail in NORDIC
- * SEMICONDUCTOR STANDARD SOFTWARE LICENSE AGREEMENT.
- *
- * Licensees are granted free, non-transferable use of the information. NO
- * WARRANTY of ANY KIND is provided. This heading must NOT be removed from
- * the file.
- *
- */
-
- #ifndef APP_TIMER_APPSH_H
- #define APP_TIMER_APPSH_H
-
-#include "app_timer.h"
-
-#ifdef __cplusplus
-extern "C" {
-#endif
-
-#define APP_TIMER_SCHED_EVT_SIZE     sizeof(app_timer_event_t)  /**< Size of button events being passed through the scheduler (is to be used for computing the maximum size of scheduler events). */
-
-/**@brief Macro for initializing the application timer module to use with app_scheduler.
- *
- * @param[in]  PRESCALER        Value of the RTC1 PRESCALER register. This will decide the
- *                              timer tick rate. Set to 0 for no prescaling.
- * @param[in]  OP_QUEUES_SIZE   Size of queues holding timer operations that are pending execution.
- * @param[in]  USE_SCHEDULER    TRUE if the application is using the app_scheduler,
- *                              FALSE otherwise.
- *
- * @note Since this macro allocates a buffer, it must only be called once (it is OK to call it
- *       several times as long as it is from the same location, e.g. to do a reinitialization).
- */
-#define APP_TIMER_APPSH_INIT(PRESCALER, OP_QUEUES_SIZE, USE_SCHEDULER)                 \
-    APP_TIMER_INIT(PRESCALER, OP_QUEUES_SIZE,                                          \
-                                (USE_SCHEDULER) ? app_timer_evt_schedule : NULL)
-
-typedef struct
-{
-    app_timer_timeout_handler_t timeout_handler;
-    void *                      p_context;
-} app_timer_event_t;
-
-uint32_t app_timer_evt_schedule(app_timer_timeout_handler_t timeout_handler,
-                                void *                      p_context);
-#ifdef __cplusplus
-}
-#endif
-
-#endif // APP_TIMER_APPSH_H
-