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/29 19:30:52 UTC

[1/7] incubator-mynewt-core git commit: Add pointers to LICENSE and .rat-excludes.

Repository: incubator-mynewt-core
Updated Branches:
  refs/heads/1_0_0_b1_dev 6bf8c3675 -> a3175ec59


Add pointers to LICENSE and .rat-excludes.

* tinycrypt
* Kinetis SDK 2.0
* STM32F4 CMSIS implementation
* lwIP


Project: http://git-wip-us.apache.org/repos/asf/incubator-mynewt-core/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-mynewt-core/commit/875c6927
Tree: http://git-wip-us.apache.org/repos/asf/incubator-mynewt-core/tree/875c6927
Diff: http://git-wip-us.apache.org/repos/asf/incubator-mynewt-core/diff/875c6927

Branch: refs/heads/1_0_0_b1_dev
Commit: 875c692741d6fd5b944b977e4bd2bfe545f16b95
Parents: 4de64d1
Author: Christopher Collins <cc...@apache.org>
Authored: Tue Nov 29 08:48:31 2016 -0800
Committer: Christopher Collins <cc...@apache.org>
Committed: Tue Nov 29 11:31:46 2016 -0800

----------------------------------------------------------------------
 .rat-excludes | 12 +++++-------
 LICENSE       | 31 +++++++++++++++++++++++++++++++
 2 files changed, 36 insertions(+), 7 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-mynewt-core/blob/875c6927/.rat-excludes
----------------------------------------------------------------------
diff --git a/.rat-excludes b/.rat-excludes
index 30c2b9e..804bbde 100644
--- a/.rat-excludes
+++ b/.rat-excludes
@@ -179,21 +179,19 @@ base64.c
 # tinycrypt - BSD License.
 tinycrypt
 
-# frdm-k64f clock configuration - BSD License.
-clock_config.c
-clock_config.h
-
 # CMSIS Cortex-M4, STM32f4 - BSD License.
 STM32F4xx
 STM32F4xx_HAL_Driver
 
-# NXP SDK - BSD License.
-sdk-2.0-frdm-k64f_b160321
+# NXP Kinetis SDK 2.0 - BSD License.
 MK64FN1M0xxx12_flash.ld
 boot-MK64FN1M0xxx12_flash.ld
+clock_config.c
+clock_config.h
+sdk-2.0-frdm-k64f_b160321
 startup_MK64F12.S
 
-# LWIP - BSD License.
+# LWIP - BSD License + a few MIT-licensed files.
 lwip_base
 
 # OIC - BSD License.

http://git-wip-us.apache.org/repos/asf/incubator-mynewt-core/blob/875c6927/LICENSE
----------------------------------------------------------------------
diff --git a/LICENSE b/LICENSE
index b9da745..f5d6984 100644
--- a/LICENSE
+++ b/LICENSE
@@ -302,3 +302,34 @@ This product bundles parts of mbed, which is available under the
     * hw/mcu/nordic/nrf51xxx/include/mcu/nrf51_deprecated.h
     * hw/mcu/nordic/nrf51xxx/include/mcu/system_nrf51.h
 
+This product bundles tinycrypt, which is available under the
+"3-clause BSD" license.  For details, see: crypto/tinycrypt
+
+This product bundles parts of the Kinetis SDK 2.0, which is available under
+the "3-clause BSD" license.  Bundled files are:
+    * hw/mcu/nxp/src/ext/sdk-2.0-frdm-k64f_b160321/*
+    * hw/bsp/frdm-k64f/boot-MK64FN1M0xxx12_flash.ld
+    * hw/bsp/frdm-k64f/MK64FN1M0xxx12_flash.ld
+    * hw/bsp/frdm-k64f/src/clock_config.c
+    * hw/bsp/frdm-k64f/src/clock_config.h
+    * hw/bsp/frdm-k64f/src/arch/cortex_m4/startup_MK64F12.S
+
+This product bundles parts of the STM32F4 CMSIS implementation, which is
+available under the "3-clause BSD" license.  For details, see:
+    * hw/mcu/stm/stm32f4xx/src/ext/Drivers/CMSIS/Device/ST/STM32F4xx
+    * hw/mcu/stm/stm32f4xx/src/ext/Drivers/STM32F4xx_HAL_Driver
+
+This product bundles lwIP.  The following files are available under the
+MIT-license:
+    * net/ip/lwip_base/include/netif/ppp/eap.h
+    * net/ip/lwip_base/include/netif/ppp/pppdebug.h
+    * net/ip/lwip_base/include/netif/ppp/ppp.h
+    * net/ip/lwip_base/include/netif/ppp/ppp_impl.h
+    * net/ip/lwip_base/src/netif/ppp/eap.c
+    * net/ip/lwip_base/src/netif/ppp/mppe.c
+    * net/ip/lwip_base/src/netif/ppp/ppp.c
+All other files in the net/ip/lwip_base are available under the "3-clause BSD"
+license.
+
+This product bundles the OCF constrained iotivity stack (OIC), which is
+available under the "3-clause BSD" license.  For details, see: net/oic


[5/7] incubator-mynewt-core git commit: lwip_base - Remove incompatibly-licensed files.

Posted by cc...@apache.org.
lwip_base - Remove incompatibly-licensed files.

These files contain the following language:

* Redistribution and use in source and binary forms are permitted
* provided that the above copyright notice and this paragraph are
* duplicated in all such forms and that any documentation,
* advertising materials, and other materials related to such
* distribution and use acknowledge that the software was developed
* by the University of California, Berkeley...

The "advertising materials" phrase is problematic.


Project: http://git-wip-us.apache.org/repos/asf/incubator-mynewt-core/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-mynewt-core/commit/a934f1ee
Tree: http://git-wip-us.apache.org/repos/asf/incubator-mynewt-core/tree/a934f1ee
Diff: http://git-wip-us.apache.org/repos/asf/incubator-mynewt-core/diff/a934f1ee

Branch: refs/heads/1_0_0_b1_dev
Commit: a934f1ee95f150683cc47846352534e7d301ed85
Parents: 875c692
Author: Christopher Collins <cc...@apache.org>
Authored: Tue Nov 29 11:28:22 2016 -0800
Committer: Christopher Collins <cc...@apache.org>
Committed: Tue Nov 29 11:32:03 2016 -0800

----------------------------------------------------------------------
 net/ip/lwip_base/include/netif/ppp/vj.h | 169 -------
 net/ip/lwip_base/src/netif/ppp/vj.c     | 695 ---------------------------
 2 files changed, 864 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-mynewt-core/blob/a934f1ee/net/ip/lwip_base/include/netif/ppp/vj.h
----------------------------------------------------------------------
diff --git a/net/ip/lwip_base/include/netif/ppp/vj.h b/net/ip/lwip_base/include/netif/ppp/vj.h
deleted file mode 100644
index b386c01..0000000
--- a/net/ip/lwip_base/include/netif/ppp/vj.h
+++ /dev/null
@@ -1,169 +0,0 @@
-/*
- * Definitions for tcp compression routines.
- *
- * $Id: vj.h,v 1.7 2010/02/22 17:52:09 goldsimon Exp $
- *
- * Copyright (c) 1989 Regents of the University of California.
- * All rights reserved.
- *
- * Redistribution and use in source and binary forms are permitted
- * provided that the above copyright notice and this paragraph are
- * duplicated in all such forms and that any documentation,
- * advertising materials, and other materials related to such
- * distribution and use acknowledge that the software was developed
- * by the University of California, Berkeley.  The name of the
- * University may not be used to endorse or promote products derived
- * from this software without specific prior written permission.
- * THIS SOFTWARE IS PROVIDED ``AS IS'' AND WITHOUT ANY EXPRESS OR
- * IMPLIED WARRANTIES, INCLUDING, WITHOUT LIMITATION, THE IMPLIED
- * WARRANTIES OF MERCHANTIBILITY AND FITNESS FOR A PARTICULAR PURPOSE.
- *
- * Van Jacobson (van@helios.ee.lbl.gov), Dec 31, 1989:
- * - Initial distribution.
- */
-
-#include "netif/ppp/ppp_opts.h"
-#if PPP_SUPPORT && VJ_SUPPORT /* don't build if not configured for use in lwipopts.h */
-
-#ifndef VJ_H
-#define VJ_H
-
-#include "lwip/ip.h"
-#include "lwip/priv/tcp_priv.h"
-
-#ifdef __cplusplus
-extern "C" {
-#endif
-
-#define MAX_SLOTS 16 /* must be > 2 and < 256 */
-#define MAX_HDR   128
-
-/*
- * Compressed packet format:
- *
- * The first octet contains the packet type (top 3 bits), TCP
- * 'push' bit, and flags that indicate which of the 4 TCP sequence
- * numbers have changed (bottom 5 bits).  The next octet is a
- * conversation number that associates a saved IP/TCP header with
- * the compressed packet.  The next two octets are the TCP checksum
- * from the original datagram.  The next 0 to 15 octets are
- * sequence number changes, one change per bit set in the header
- * (there may be no changes and there are two special cases where
- * the receiver implicitly knows what changed -- see below).
- *
- * There are 5 numbers which can change (they are always inserted
- * in the following order): TCP urgent pointer, window,
- * acknowlegement, sequence number and IP ID.  (The urgent pointer
- * is different from the others in that its value is sent, not the
- * change in value.)  Since typical use of SLIP links is biased
- * toward small packets (see comments on MTU/MSS below), changes
- * use a variable length coding with one octet for numbers in the
- * range 1 - 255 and 3 octets (0, MSB, LSB) for numbers in the
- * range 256 - 65535 or 0.  (If the change in sequence number or
- * ack is more than 65535, an uncompressed packet is sent.)
- */
-
-/*
- * Packet types (must not conflict with IP protocol version)
- *
- * The top nibble of the first octet is the packet type.  There are
- * three possible types: IP (not proto TCP or tcp with one of the
- * control flags set); uncompressed TCP (a normal IP/TCP packet but
- * with the 8-bit protocol field replaced by an 8-bit connection id --
- * this type of packet syncs the sender & receiver); and compressed
- * TCP (described above).
- *
- * LSB of 4-bit field is TCP "PUSH" bit (a worthless anachronism) and
- * is logically part of the 4-bit "changes" field that follows.  Top
- * three bits are actual packet type.  For backward compatibility
- * and in the interest of conserving bits, numbers are chosen so the
- * IP protocol version number (4) which normally appears in this nibble
- * means "IP packet".
- */
-
-/* packet types */
-#define TYPE_IP               0x40
-#define TYPE_UNCOMPRESSED_TCP 0x70
-#define TYPE_COMPRESSED_TCP   0x80
-#define TYPE_ERROR            0x00
-
-/* Bits in first octet of compressed packet */
-#define NEW_C 0x40 /* flag bits for what changed in a packet */
-#define NEW_I 0x20
-#define NEW_S 0x08
-#define NEW_A 0x04
-#define NEW_W 0x02
-#define NEW_U 0x01
-
-/* reserved, special-case values of above */
-#define SPECIAL_I (NEW_S|NEW_W|NEW_U) /* echoed interactive traffic */
-#define SPECIAL_D (NEW_S|NEW_A|NEW_W|NEW_U) /* unidirectional data */
-#define SPECIALS_MASK (NEW_S|NEW_A|NEW_W|NEW_U)
-
-#define TCP_PUSH_BIT 0x10
-
-
-/*
- * "state" data for each active tcp conversation on the wire.  This is
- * basically a copy of the entire IP/TCP header from the last packet
- * we saw from the conversation together with a small identifier
- * the transmit & receive ends of the line use to locate saved header.
- */
-struct cstate {
-  struct cstate *cs_next; /* next most recently used state (xmit only) */
-  u16_t cs_hlen;        /* size of hdr (receive only) */
-  u8_t cs_id;           /* connection # associated with this state */
-  u8_t cs_filler;
-  union {
-    char csu_hdr[MAX_HDR];
-    struct ip_hdr csu_ip;     /* ip/tcp hdr from most recent packet */
-  } vjcs_u;
-};
-#define cs_ip vjcs_u.csu_ip
-#define cs_hdr vjcs_u.csu_hdr
-
-
-struct vjstat {
-  u32_t vjs_packets;        /* outbound packets */
-  u32_t vjs_compressed;     /* outbound compressed packets */
-  u32_t vjs_searches;       /* searches for connection state */
-  u32_t vjs_misses;         /* times couldn't find conn. state */
-  u32_t vjs_uncompressedin; /* inbound uncompressed packets */
-  u32_t vjs_compressedin;   /* inbound compressed packets */
-  u32_t vjs_errorin;        /* inbound unknown type packets */
-  u32_t vjs_tossed;         /* inbound packets tossed because of error */
-};
-
-/*
- * all the state data for one serial line (we need one of these per line).
- */
-struct vjcompress {
-  struct cstate *last_cs;          /* most recently used tstate */
-  u8_t last_recv;                /* last rcvd conn. id */
-  u8_t last_xmit;                /* last sent conn. id */
-  u16_t flags;
-  u8_t maxSlotIndex;
-  u8_t compressSlot;             /* Flag indicating OK to compress slot ID. */
-#if LINK_STATS
-  struct vjstat stats;
-#endif
-  struct cstate tstate[MAX_SLOTS]; /* xmit connection states */
-  struct cstate rstate[MAX_SLOTS]; /* receive connection states */
-};
-
-/* flag values */
-#define VJF_TOSS 1U /* tossing rcvd frames because of input err */
-
-extern void  vj_compress_init    (struct vjcompress *comp);
-extern u8_t  vj_compress_tcp     (struct vjcompress *comp, struct pbuf **pb);
-extern void  vj_uncompress_err   (struct vjcompress *comp);
-extern int   vj_uncompress_uncomp(struct pbuf *nb, struct vjcompress *comp);
-extern int   vj_uncompress_tcp   (struct pbuf **nb, struct vjcompress *comp);
-
-#endif /* VJ_H */
-
-#ifdef __cplusplus
-}
-#endif
-
-#endif /* PPP_SUPPORT && VJ_SUPPORT */

http://git-wip-us.apache.org/repos/asf/incubator-mynewt-core/blob/a934f1ee/net/ip/lwip_base/src/netif/ppp/vj.c
----------------------------------------------------------------------
diff --git a/net/ip/lwip_base/src/netif/ppp/vj.c b/net/ip/lwip_base/src/netif/ppp/vj.c
deleted file mode 100644
index dadb38d..0000000
--- a/net/ip/lwip_base/src/netif/ppp/vj.c
+++ /dev/null
@@ -1,695 +0,0 @@
-/*
- * Routines to compress and uncompess tcp packets (for transmission
- * over low speed serial lines.
- *
- * Copyright (c) 1989 Regents of the University of California.
- * All rights reserved.
- *
- * Redistribution and use in source and binary forms are permitted
- * provided that the above copyright notice and this paragraph are
- * duplicated in all such forms and that any documentation,
- * advertising materials, and other materials related to such
- * distribution and use acknowledge that the software was developed
- * by the University of California, Berkeley.  The name of the
- * University may not be used to endorse or promote products derived
- * from this software without specific prior written permission.
- * THIS SOFTWARE IS PROVIDED ``AS IS'' AND WITHOUT ANY EXPRESS OR
- * IMPLIED WARRANTIES, INCLUDING, WITHOUT LIMITATION, THE IMPLIED
- * WARRANTIES OF MERCHANTIBILITY AND FITNESS FOR A PARTICULAR PURPOSE.
- *
- * Van Jacobson (van@helios.ee.lbl.gov), Dec 31, 1989:
- *   Initial distribution.
- *
- * Modified June 1993 by Paul Mackerras, paulus@cs.anu.edu.au,
- * so that the entire packet being decompressed doesn't have
- * to be in contiguous memory (just the compressed header).
- *
- * Modified March 1998 by Guy Lancaster, glanca@gesn.com,
- * for a 16 bit processor.
- */
-
-#include "netif/ppp/ppp_opts.h"
-#if PPP_SUPPORT && VJ_SUPPORT /* don't build if not configured for use in lwipopts.h */
-
-#include "netif/ppp/ppp_impl.h"
-#include "netif/ppp/pppdebug.h"
-
-#include "netif/ppp/vj.h"
-
-#include <string.h>
-
-#if LINK_STATS
-#define INCR(counter) ++comp->stats.counter
-#else
-#define INCR(counter)
-#endif
-
-void
-vj_compress_init(struct vjcompress *comp)
-{
-  u8_t i;
-  struct cstate *tstate = comp->tstate;
-
-#if MAX_SLOTS == 0
-  memset((char *)comp, 0, sizeof(*comp));
-#endif
-  comp->maxSlotIndex = MAX_SLOTS - 1;
-  comp->compressSlot = 0;    /* Disable slot ID compression by default. */
-  for (i = MAX_SLOTS - 1; i > 0; --i) {
-    tstate[i].cs_id = i;
-    tstate[i].cs_next = &tstate[i - 1];
-  }
-  tstate[0].cs_next = &tstate[MAX_SLOTS - 1];
-  tstate[0].cs_id = 0;
-  comp->last_cs = &tstate[0];
-  comp->last_recv = 255;
-  comp->last_xmit = 255;
-  comp->flags = VJF_TOSS;
-}
-
-
-/* ENCODE encodes a number that is known to be non-zero.  ENCODEZ
- * checks for zero (since zero has to be encoded in the long, 3 byte
- * form).
- */
-#define ENCODE(n) { \
-  if ((u16_t)(n) >= 256) { \
-    *cp++ = 0; \
-    cp[1] = (u8_t)(n); \
-    cp[0] = (u8_t)((n) >> 8); \
-    cp += 2; \
-  } else { \
-    *cp++ = (u8_t)(n); \
-  } \
-}
-#define ENCODEZ(n) { \
-  if ((u16_t)(n) >= 256 || (u16_t)(n) == 0) { \
-    *cp++ = 0; \
-    cp[1] = (u8_t)(n); \
-    cp[0] = (u8_t)((n) >> 8); \
-    cp += 2; \
-  } else { \
-    *cp++ = (u8_t)(n); \
-  } \
-}
-
-#define DECODEL(f) { \
-  if (*cp == 0) {\
-    u32_t tmp_ = ntohl(f) + ((cp[1] << 8) | cp[2]); \
-    (f) = htonl(tmp_); \
-    cp += 3; \
-  } else { \
-    u32_t tmp_ = ntohl(f) + (u32_t)*cp++; \
-    (f) = htonl(tmp_); \
-  } \
-}
-
-#define DECODES(f) { \
-  if (*cp == 0) {\
-    u16_t tmp_ = ntohs(f) + (((u16_t)cp[1] << 8) | cp[2]); \
-    (f) = htons(tmp_); \
-    cp += 3; \
-  } else { \
-    u16_t tmp_ = ntohs(f) + (u16_t)*cp++; \
-    (f) = htons(tmp_); \
-  } \
-}
-
-#define DECODEU(f) { \
-  if (*cp == 0) {\
-    (f) = htons(((u16_t)cp[1] << 8) | cp[2]); \
-    cp += 3; \
-  } else { \
-    (f) = htons((u16_t)*cp++); \
-  } \
-}
-
-/* Helper structures for unaligned *u32_t and *u16_t accesses */
-#ifdef PACK_STRUCT_USE_INCLUDES
-#  include "arch/bpstruct.h"
-#endif
-PACK_STRUCT_BEGIN
-struct vj_u32_t {
-  PACK_STRUCT_FIELD(u32_t v);
-} PACK_STRUCT_STRUCT;
-PACK_STRUCT_END
-#ifdef PACK_STRUCT_USE_INCLUDES
-#  include "arch/epstruct.h"
-#endif
-
-#ifdef PACK_STRUCT_USE_INCLUDES
-#  include "arch/bpstruct.h"
-#endif
-PACK_STRUCT_BEGIN
-struct vj_u16_t {
-  PACK_STRUCT_FIELD(u16_t v);
-} PACK_STRUCT_STRUCT;
-PACK_STRUCT_END
-#ifdef PACK_STRUCT_USE_INCLUDES
-#  include "arch/epstruct.h"
-#endif
-
-/*
- * vj_compress_tcp - Attempt to do Van Jacobson header compression on a
- * packet.  This assumes that nb and comp are not null and that the first
- * buffer of the chain contains a valid IP header.
- * Return the VJ type code indicating whether or not the packet was
- * compressed.
- */
-u8_t
-vj_compress_tcp(struct vjcompress *comp, struct pbuf **pb)
-{
-  struct pbuf *np = *pb;
-  struct ip_hdr *ip = (struct ip_hdr *)np->payload;
-  struct cstate *cs = comp->last_cs->cs_next;
-  u16_t ilen = IPH_HL(ip);
-  u16_t hlen;
-  struct tcp_hdr *oth;
-  struct tcp_hdr *th;
-  u16_t deltaS, deltaA = 0;
-  u32_t deltaL;
-  u32_t changes = 0;
-  u8_t new_seq[16];
-  u8_t *cp = new_seq;
-
-  /*
-   * Check that the packet is IP proto TCP.
-   */
-  if (IPH_PROTO(ip) != IP_PROTO_TCP) {
-    return (TYPE_IP);
-  }
-
-  /*
-   * Bail if this is an IP fragment or if the TCP packet isn't
-   * `compressible' (i.e., ACK isn't set or some other control bit is
-   * set).
-   */
-  if ((IPH_OFFSET(ip) & PP_HTONS(0x3fff)) || np->tot_len < 40) {
-    return (TYPE_IP);
-  }
-  th = (struct tcp_hdr *)&((struct vj_u32_t*)ip)[ilen];
-  if ((TCPH_FLAGS(th) & (TCP_SYN|TCP_FIN|TCP_RST|TCP_ACK)) != TCP_ACK) {
-    return (TYPE_IP);
-  }
-
-  /* Check that the TCP/IP headers are contained in the first buffer. */
-  hlen = ilen + TCPH_HDRLEN(th);
-  hlen <<= 2;
-  if (np->len < hlen) {
-    PPPDEBUG(LOG_INFO, ("vj_compress_tcp: header len %d spans buffers\n", hlen));
-    return (TYPE_IP);
-  }
-
-  /* TCP stack requires that we don't change the packet payload, therefore we copy
-   * the whole packet before compression. */
-  np = pbuf_alloc(PBUF_RAW, np->tot_len, PBUF_POOL);
-  if (!np) {
-    return (TYPE_IP);
-  }
-
-  if (pbuf_copy(np, *pb) != ERR_OK) {
-    pbuf_free(np);
-    return (TYPE_IP);
-  }
-
-  *pb = np;
-  ip = (struct ip_hdr *)np->payload;
-
-  /*
-   * Packet is compressible -- we're going to send either a
-   * COMPRESSED_TCP or UNCOMPRESSED_TCP packet.  Either way we need
-   * to locate (or create) the connection state.  Special case the
-   * most recently used connection since it's most likely to be used
-   * again & we don't have to do any reordering if it's used.
-   */
-  INCR(vjs_packets);
-  if (!ip4_addr_cmp(&ip->src, &cs->cs_ip.src)
-      || !ip4_addr_cmp(&ip->dest, &cs->cs_ip.dest)
-      || (*(struct vj_u32_t*)th).v != (((struct vj_u32_t*)&cs->cs_ip)[IPH_HL(&cs->cs_ip)]).v) {
-    /*
-     * Wasn't the first -- search for it.
-     *
-     * States are kept in a circularly linked list with
-     * last_cs pointing to the end of the list.  The
-     * list is kept in lru order by moving a state to the
-     * head of the list whenever it is referenced.  Since
-     * the list is short and, empirically, the connection
-     * we want is almost always near the front, we locate
-     * states via linear search.  If we don't find a state
-     * for the datagram, the oldest state is (re-)used.
-     */
-    struct cstate *lcs;
-    struct cstate *lastcs = comp->last_cs;
-
-    do {
-      lcs = cs; cs = cs->cs_next;
-      INCR(vjs_searches);
-      if (ip4_addr_cmp(&ip->src, &cs->cs_ip.src)
-          && ip4_addr_cmp(&ip->dest, &cs->cs_ip.dest)
-          && (*(struct vj_u32_t*)th).v == (((struct vj_u32_t*)&cs->cs_ip)[IPH_HL(&cs->cs_ip)]).v) {
-        goto found;
-      }
-    } while (cs != lastcs);
-
-    /*
-     * Didn't find it -- re-use oldest cstate.  Send an
-     * uncompressed packet that tells the other side what
-     * connection number we're using for this conversation.
-     * Note that since the state list is circular, the oldest
-     * state points to the newest and we only need to set
-     * last_cs to update the lru linkage.
-     */
-    INCR(vjs_misses);
-    comp->last_cs = lcs;
-    goto uncompressed;
-
-    found:
-    /*
-     * Found it -- move to the front on the connection list.
-     */
-    if (cs == lastcs) {
-      comp->last_cs = lcs;
-    } else {
-      lcs->cs_next = cs->cs_next;
-      cs->cs_next = lastcs->cs_next;
-      lastcs->cs_next = cs;
-    }
-  }
-
-  oth = (struct tcp_hdr *)&((struct vj_u32_t*)&cs->cs_ip)[ilen];
-  deltaS = ilen;
-
-  /*
-   * Make sure that only what we expect to change changed. The first
-   * line of the `if' checks the IP protocol version, header length &
-   * type of service.  The 2nd line checks the "Don't fragment" bit.
-   * The 3rd line checks the time-to-live and protocol (the protocol
-   * check is unnecessary but costless).  The 4th line checks the TCP
-   * header length.  The 5th line checks IP options, if any.  The 6th
-   * line checks TCP options, if any.  If any of these things are
-   * different between the previous & current datagram, we send the
-   * current datagram `uncompressed'.
-   */
-  if ((((struct vj_u16_t*)ip)[0]).v != (((struct vj_u16_t*)&cs->cs_ip)[0]).v
-      || (((struct vj_u16_t*)ip)[3]).v != (((struct vj_u16_t*)&cs->cs_ip)[3]).v
-      || (((struct vj_u16_t*)ip)[4]).v != (((struct vj_u16_t*)&cs->cs_ip)[4]).v
-      || TCPH_HDRLEN(th) != TCPH_HDRLEN(oth)
-      || (deltaS > 5 && BCMP(ip + 1, &cs->cs_ip + 1, (deltaS - 5) << 2))
-      || (TCPH_HDRLEN(th) > 5 && BCMP(th + 1, oth + 1, (TCPH_HDRLEN(th) - 5) << 2))) {
-    goto uncompressed;
-  }
-
-  /*
-   * Figure out which of the changing fields changed.  The
-   * receiver expects changes in the order: urgent, window,
-   * ack, seq (the order minimizes the number of temporaries
-   * needed in this section of code).
-   */
-  if (TCPH_FLAGS(th) & TCP_URG) {
-    deltaS = ntohs(th->urgp);
-    ENCODEZ(deltaS);
-    changes |= NEW_U;
-  } else if (th->urgp != oth->urgp) {
-    /* argh! URG not set but urp changed -- a sensible
-     * implementation should never do this but RFC793
-     * doesn't prohibit the change so we have to deal
-     * with it. */
-    goto uncompressed;
-  }
-
-  if ((deltaS = (u16_t)(ntohs(th->wnd) - ntohs(oth->wnd))) != 0) {
-    ENCODE(deltaS);
-    changes |= NEW_W;
-  }
-
-  if ((deltaL = ntohl(th->ackno) - ntohl(oth->ackno)) != 0) {
-    if (deltaL > 0xffff) {
-      goto uncompressed;
-    }
-    deltaA = (u16_t)deltaL;
-    ENCODE(deltaA);
-    changes |= NEW_A;
-  }
-
-  if ((deltaL = ntohl(th->seqno) - ntohl(oth->seqno)) != 0) {
-    if (deltaL > 0xffff) {
-      goto uncompressed;
-    }
-    deltaS = (u16_t)deltaL;
-    ENCODE(deltaS);
-    changes |= NEW_S;
-  }
-
-  switch(changes) {
-  case 0:
-    /*
-     * Nothing changed. If this packet contains data and the
-     * last one didn't, this is probably a data packet following
-     * an ack (normal on an interactive connection) and we send
-     * it compressed.  Otherwise it's probably a retransmit,
-     * retransmitted ack or window probe.  Send it uncompressed
-     * in case the other side missed the compressed version.
-     */
-    if (IPH_LEN(ip) != IPH_LEN(&cs->cs_ip) &&
-      ntohs(IPH_LEN(&cs->cs_ip)) == hlen) {
-      break;
-    }
-    /* no break */
-    /* fall through */
-
-  case SPECIAL_I:
-  case SPECIAL_D:
-    /*
-     * actual changes match one of our special case encodings --
-     * send packet uncompressed.
-     */
-    goto uncompressed;
-
-  case NEW_S|NEW_A:
-    if (deltaS == deltaA && deltaS == ntohs(IPH_LEN(&cs->cs_ip)) - hlen) {
-      /* special case for echoed terminal traffic */
-      changes = SPECIAL_I;
-      cp = new_seq;
-    }
-    break;
-
-  case NEW_S:
-    if (deltaS == ntohs(IPH_LEN(&cs->cs_ip)) - hlen) {
-      /* special case for data xfer */
-      changes = SPECIAL_D;
-      cp = new_seq;
-    }
-    break;
-  default:
-     break;
-  }
-
-  deltaS = (u16_t)(ntohs(IPH_ID(ip)) - ntohs(IPH_ID(&cs->cs_ip)));
-  if (deltaS != 1) {
-    ENCODEZ(deltaS);
-    changes |= NEW_I;
-  }
-  if (TCPH_FLAGS(th) & TCP_PSH) {
-    changes |= TCP_PUSH_BIT;
-  }
-  /*
-   * Grab the cksum before we overwrite it below.  Then update our
-   * state with this packet's header.
-   */
-  deltaA = ntohs(th->chksum);
-  MEMCPY(&cs->cs_ip, ip, hlen);
-
-  /*
-   * We want to use the original packet as our compressed packet.
-   * (cp - new_seq) is the number of bytes we need for compressed
-   * sequence numbers.  In addition we need one byte for the change
-   * mask, one for the connection id and two for the tcp checksum.
-   * So, (cp - new_seq) + 4 bytes of header are needed.  hlen is how
-   * many bytes of the original packet to toss so subtract the two to
-   * get the new packet size.
-   */
-  deltaS = (u16_t)(cp - new_seq);
-  if (!comp->compressSlot || comp->last_xmit != cs->cs_id) {
-    comp->last_xmit = cs->cs_id;
-    hlen -= deltaS + 4;
-    if (pbuf_header(np, -(s16_t)hlen)){
-      /* Can we cope with this failing?  Just assert for now */
-      LWIP_ASSERT("pbuf_header failed\n", 0);
-    }
-    cp = (u8_t*)np->payload;
-    *cp++ = (u8_t)(changes | NEW_C);
-    *cp++ = cs->cs_id;
-  } else {
-    hlen -= deltaS + 3;
-    if (pbuf_header(np, -(s16_t)hlen)) {
-      /* Can we cope with this failing?  Just assert for now */
-      LWIP_ASSERT("pbuf_header failed\n", 0);
-    }
-    cp = (u8_t*)np->payload;
-    *cp++ = (u8_t)changes;
-  }
-  *cp++ = (u8_t)(deltaA >> 8);
-  *cp++ = (u8_t)deltaA;
-  MEMCPY(cp, new_seq, deltaS);
-  INCR(vjs_compressed);
-  return (TYPE_COMPRESSED_TCP);
-
-  /*
-   * Update connection state cs & send uncompressed packet (that is,
-   * a regular ip/tcp packet but with the 'conversation id' we hope
-   * to use on future compressed packets in the protocol field).
-   */
-uncompressed:
-  MEMCPY(&cs->cs_ip, ip, hlen);
-  IPH_PROTO_SET(ip, cs->cs_id);
-  comp->last_xmit = cs->cs_id;
-  return (TYPE_UNCOMPRESSED_TCP);
-}
-
-/*
- * Called when we may have missed a packet.
- */
-void
-vj_uncompress_err(struct vjcompress *comp)
-{
-  comp->flags |= VJF_TOSS;
-  INCR(vjs_errorin);
-}
-
-/*
- * "Uncompress" a packet of type TYPE_UNCOMPRESSED_TCP.
- * Return 0 on success, -1 on failure.
- */
-int
-vj_uncompress_uncomp(struct pbuf *nb, struct vjcompress *comp)
-{
-  u32_t hlen;
-  struct cstate *cs;
-  struct ip_hdr *ip;
-
-  ip = (struct ip_hdr *)nb->payload;
-  hlen = IPH_HL(ip) << 2;
-  if (IPH_PROTO(ip) >= MAX_SLOTS
-      || hlen + sizeof(struct tcp_hdr) > nb->len
-      || (hlen += TCPH_HDRLEN(((struct tcp_hdr *)&((char *)ip)[hlen])) << 2)
-          > nb->len
-      || hlen > MAX_HDR) {
-    PPPDEBUG(LOG_INFO, ("vj_uncompress_uncomp: bad cid=%d, hlen=%d buflen=%d\n",
-      IPH_PROTO(ip), hlen, nb->len));
-    comp->flags |= VJF_TOSS;
-    INCR(vjs_errorin);
-    return -1;
-  }
-  cs = &comp->rstate[comp->last_recv = IPH_PROTO(ip)];
-  comp->flags &=~ VJF_TOSS;
-  IPH_PROTO_SET(ip, IP_PROTO_TCP);
-  MEMCPY(&cs->cs_ip, ip, hlen);
-  cs->cs_hlen = (u16_t)hlen;
-  INCR(vjs_uncompressedin);
-  return 0;
-}
-
-/*
- * Uncompress a packet of type TYPE_COMPRESSED_TCP.
- * The packet is composed of a buffer chain and the first buffer
- * must contain an accurate chain length.
- * The first buffer must include the entire compressed TCP/IP header.
- * This procedure replaces the compressed header with the uncompressed
- * header and returns the length of the VJ header.
- */
-int
-vj_uncompress_tcp(struct pbuf **nb, struct vjcompress *comp)
-{
-  u8_t *cp;
-  struct tcp_hdr *th;
-  struct cstate *cs;
-  struct vj_u16_t *bp;
-  struct pbuf *n0 = *nb;
-  u32_t tmp;
-  u32_t vjlen, hlen, changes;
-
-  INCR(vjs_compressedin);
-  cp = (u8_t*)n0->payload;
-  changes = *cp++;
-  if (changes & NEW_C) {
-    /*
-     * Make sure the state index is in range, then grab the state.
-     * If we have a good state index, clear the 'discard' flag.
-     */
-    if (*cp >= MAX_SLOTS) {
-      PPPDEBUG(LOG_INFO, ("vj_uncompress_tcp: bad cid=%d\n", *cp));
-      goto bad;
-    }
-
-    comp->flags &=~ VJF_TOSS;
-    comp->last_recv = *cp++;
-  } else {
-    /*
-     * this packet has an implicit state index.  If we've
-     * had a line error since the last time we got an
-     * explicit state index, we have to toss the packet.
-     */
-    if (comp->flags & VJF_TOSS) {
-      PPPDEBUG(LOG_INFO, ("vj_uncompress_tcp: tossing\n"));
-      INCR(vjs_tossed);
-      return (-1);
-    }
-  }
-  cs = &comp->rstate[comp->last_recv];
-  hlen = IPH_HL(&cs->cs_ip) << 2;
-  th = (struct tcp_hdr *)&((u8_t*)&cs->cs_ip)[hlen];
-  th->chksum = htons((*cp << 8) | cp[1]);
-  cp += 2;
-  if (changes & TCP_PUSH_BIT) {
-    TCPH_SET_FLAG(th, TCP_PSH);
-  } else {
-    TCPH_UNSET_FLAG(th, TCP_PSH);
-  }
-
-  switch (changes & SPECIALS_MASK) {
-  case SPECIAL_I:
-    {
-      u32_t i = ntohs(IPH_LEN(&cs->cs_ip)) - cs->cs_hlen;
-      /* some compilers can't nest inline assembler.. */
-      tmp = ntohl(th->ackno) + i;
-      th->ackno = htonl(tmp);
-      tmp = ntohl(th->seqno) + i;
-      th->seqno = htonl(tmp);
-    }
-    break;
-
-  case SPECIAL_D:
-    /* some compilers can't nest inline assembler.. */
-    tmp = ntohl(th->seqno) + ntohs(IPH_LEN(&cs->cs_ip)) - cs->cs_hlen;
-    th->seqno = htonl(tmp);
-    break;
-
-  default:
-    if (changes & NEW_U) {
-      TCPH_SET_FLAG(th, TCP_URG);
-      DECODEU(th->urgp);
-    } else {
-      TCPH_UNSET_FLAG(th, TCP_URG);
-    }
-    if (changes & NEW_W) {
-      DECODES(th->wnd);
-    }
-    if (changes & NEW_A) {
-      DECODEL(th->ackno);
-    }
-    if (changes & NEW_S) {
-      DECODEL(th->seqno);
-    }
-    break;
-  }
-  if (changes & NEW_I) {
-    DECODES(cs->cs_ip._id);
-  } else {
-    IPH_ID_SET(&cs->cs_ip, ntohs(IPH_ID(&cs->cs_ip)) + 1);
-    IPH_ID_SET(&cs->cs_ip, htons(IPH_ID(&cs->cs_ip)));
-  }
-
-  /*
-   * At this point, cp points to the first byte of data in the
-   * packet.  Fill in the IP total length and update the IP
-   * header checksum.
-   */
-  vjlen = (u16_t)(cp - (u8_t*)n0->payload);
-  if (n0->len < vjlen) {
-    /*
-     * We must have dropped some characters (crc should detect
-     * this but the old slip framing won't)
-     */
-    PPPDEBUG(LOG_INFO, ("vj_uncompress_tcp: head buffer %d too short %d\n",
-          n0->len, vjlen));
-    goto bad;
-  }
-
-#if BYTE_ORDER == LITTLE_ENDIAN
-  tmp = n0->tot_len - vjlen + cs->cs_hlen;
-  IPH_LEN_SET(&cs->cs_ip, htons((u16_t)tmp));
-#else
-  IPH_LEN_SET(&cs->cs_ip, htons(n0->tot_len - vjlen + cs->cs_hlen));
-#endif
-
-  /* recompute the ip header checksum */
-  bp = (struct vj_u16_t*) &cs->cs_ip;
-  IPH_CHKSUM_SET(&cs->cs_ip, 0);
-  for (tmp = 0; hlen > 0; hlen -= 2) {
-    tmp += (*bp++).v;
-  }
-  tmp = (tmp & 0xffff) + (tmp >> 16);
-  tmp = (tmp & 0xffff) + (tmp >> 16);
-  IPH_CHKSUM_SET(&cs->cs_ip,  (u16_t)(~tmp));
-
-  /* Remove the compressed header and prepend the uncompressed header. */
-  if (pbuf_header(n0, -(s16_t)vjlen)) {
-    /* Can we cope with this failing?  Just assert for now */
-    LWIP_ASSERT("pbuf_header failed\n", 0);
-    goto bad;
-  }
-
-  if(LWIP_MEM_ALIGN(n0->payload) != n0->payload) {
-    struct pbuf *np, *q;
-    u8_t *bufptr;
-
-#if IP_FORWARD
-    /* If IP forwarding is enabled we are using a PBUF_LINK packet type so
-     * the packet is being allocated with enough header space to be
-     * forwarded (to Ethernet for example).
-     */
-    np = pbuf_alloc(PBUF_LINK, n0->len + cs->cs_hlen, PBUF_POOL);
-#else /* IP_FORWARD */
-    np = pbuf_alloc(PBUF_RAW, n0->len + cs->cs_hlen, PBUF_POOL);
-#endif /* IP_FORWARD */
-    if(!np) {
-      PPPDEBUG(LOG_WARNING, ("vj_uncompress_tcp: realign failed\n"));
-      goto bad;
-    }
-
-    if (pbuf_header(np, -(s16_t)cs->cs_hlen)) {
-      /* Can we cope with this failing?  Just assert for now */
-      LWIP_ASSERT("pbuf_header failed\n", 0);
-      goto bad;
-    }
-
-    bufptr = (u8_t*)n0->payload;
-    for(q = np; q != NULL; q = q->next) {
-      MEMCPY(q->payload, bufptr, q->len);
-      bufptr += q->len;
-    }
-
-    if(n0->next) {
-      pbuf_chain(np, n0->next);
-      pbuf_dechain(n0);
-    }
-    pbuf_free(n0);
-    n0 = np;
-  }
-
-  if (pbuf_header(n0, (s16_t)cs->cs_hlen)) {
-    struct pbuf *np;
-
-    LWIP_ASSERT("vj_uncompress_tcp: cs->cs_hlen <= PBUF_POOL_BUFSIZE", cs->cs_hlen <= PBUF_POOL_BUFSIZE);
-    np = pbuf_alloc(PBUF_RAW, cs->cs_hlen, PBUF_POOL);
-    if(!np) {
-      PPPDEBUG(LOG_WARNING, ("vj_uncompress_tcp: prepend failed\n"));
-      goto bad;
-    }
-    pbuf_cat(np, n0);
-    n0 = np;
-  }
-  LWIP_ASSERT("n0->len >= cs->cs_hlen", n0->len >= cs->cs_hlen);
-  MEMCPY(n0->payload, &cs->cs_ip, cs->cs_hlen);
-
-  *nb = n0;
-
-  return vjlen;
-
-bad:
-  comp->flags |= VJF_TOSS;
-  INCR(vjs_errorin);
-  return (-1);
-}
-
-#endif /* PPP_SUPPORT && VJ_SUPPORT */


[6/7] incubator-mynewt-core git commit: lwip_base - Fix read of uninitialized variable.

Posted by cc...@apache.org.
lwip_base - Fix read of uninitialized variable.


Project: http://git-wip-us.apache.org/repos/asf/incubator-mynewt-core/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-mynewt-core/commit/01e86707
Tree: http://git-wip-us.apache.org/repos/asf/incubator-mynewt-core/tree/01e86707
Diff: http://git-wip-us.apache.org/repos/asf/incubator-mynewt-core/diff/01e86707

Branch: refs/heads/1_0_0_b1_dev
Commit: 01e86707d509c8bc7d7afd7e1bdd464c7ee7a3f5
Parents: a934f1e
Author: Christopher Collins <cc...@apache.org>
Authored: Tue Nov 29 11:29:19 2016 -0800
Committer: Christopher Collins <cc...@apache.org>
Committed: Tue Nov 29 11:32:03 2016 -0800

----------------------------------------------------------------------
 net/ip/src/lwip_socket.c | 1 +
 1 file changed, 1 insertion(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-mynewt-core/blob/01e86707/net/ip/src/lwip_socket.c
----------------------------------------------------------------------
diff --git a/net/ip/src/lwip_socket.c b/net/ip/src/lwip_socket.c
index ddf7be7..36e8e0e 100644
--- a/net/ip/src/lwip_socket.c
+++ b/net/ip/src/lwip_socket.c
@@ -448,6 +448,7 @@ lwip_stream_tx(struct lwip_sock *s, int notify)
     struct os_mbuf *m;
     struct os_mbuf *n;
 
+    rc = 0;
     while (s->ls_tx && rc == 0) {
         m = s->ls_tx;
         n = SLIST_NEXT(m, om_next);


[2/7] incubator-mynewt-core git commit: .rat-excludes - account for rm'd nordic SDK files.

Posted by cc...@apache.org.
.rat-excludes - account for rm'd nordic SDK files.


Project: http://git-wip-us.apache.org/repos/asf/incubator-mynewt-core/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-mynewt-core/commit/e43eb6ec
Tree: http://git-wip-us.apache.org/repos/asf/incubator-mynewt-core/tree/e43eb6ec
Diff: http://git-wip-us.apache.org/repos/asf/incubator-mynewt-core/diff/e43eb6ec

Branch: refs/heads/1_0_0_b1_dev
Commit: e43eb6ec10e798056f8b06e20ccef58457efa38f
Parents: 7ef94b8
Author: Christopher Collins <cc...@apache.org>
Authored: Tue Nov 29 09:09:17 2016 -0800
Committer: Christopher Collins <cc...@apache.org>
Committed: Tue Nov 29 11:31:46 2016 -0800

----------------------------------------------------------------------
 .rat-excludes | 61 +++++++++++++++++++++---------------------------------
 1 file changed, 24 insertions(+), 37 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-mynewt-core/blob/e43eb6ec/.rat-excludes
----------------------------------------------------------------------
diff --git a/.rat-excludes b/.rat-excludes
index ca1a212..30c2b9e 100644
--- a/.rat-excludes
+++ b/.rat-excludes
@@ -15,66 +15,53 @@ repository.yml
 crc16.*
 
 # Nordic nRF51 SDK - BSD License.
-boot-nrf51dk.ld
-nrf51dk.ld
-nrf51dk_no_boot.ld
-system_nrf51.c
-gcc_startup_nrf51.s
-boot-nrf51dk-16kbram.ld
-nrf51dk-16kbram.ld
-nrf51dk-16kbram_no_boot.ld
-boot-nrf51-arduino_101.ld
-nrf51-arduino_101.ld
 boot-nrf51xxaa.ld
-nrf51xxaa.ld
 boot-nrf51xxac.ld
-nrf51xxac.ld
-split-nrf51dk.ld
-boot-nrf51xxac.ld
-nrf51xxac.ld
-split-nrf51dk.ld
-split-nrf51dk-16kbram.ld
-nrf51.ld
+gcc_startup_nrf51.s
+gcc_startup_nrf51_split.s
 nrf51.h
-nrf51422_peripherals.h
-nrf51822_peripherals.h
+nrf51.ld
 nrf51_bitfields.h
 nrf51_deprecated.h
+nrf51dk-16kbram_no_boot.ld
+nrf51dk_no_boot.ld
+nrf51xxaa.ld
+nrf51xxac.ld
+split-nrf51dk-16kbram.ld
+split-nrf51dk.ld
+system_nrf51.c
 system_nrf51.h
-gcc_startup_nrf51_split.s
 
 # Nordic nRF52 SDK - BSD License.
-nrf52dk_no_boot.ld
 bmd300eval_no_boot.ld
 boot-nrf52xxaa.ld
+gcc_startup_nrf52.s
+gcc_startup_nrf52_split.s
+nrf51_to_nrf52.h
+nrf52.h
+nrf52.ld
+nrf52_bitfields.h
+nrf52dk_no_boot.ld
 nrf52xxaa.ld
 primo_no_boot.ld
-split-primo.ld
+rb-nano2_no_boot.ld
 split-bmd300eval.ld
 split-nrf52dk.ld
-rb-nano2_no_boot.ld
+split-primo.ld
 split-rb-nano2.ld
-nrf52.ld
 system_nrf52.c
-gcc_startup_nrf52.s
-nrf51_to_nrf52.h
-nrf52.h
-nrf52832_peripherals.h
-nrf52_bitfields.h
 system_nrf52.h
-gcc_startup_nrf52_split.s
 
-# Nordic nRF51 SDK - BSD License.
-# Nordic nRF52 SDK - BSD License.
+# Nordic nRF5x SDK - BSD License.
+arm_startup_nrf51.s
+arm_startup_nrf52.s
 compiler_abstraction.h
+iar_startup_nrf51.s
+iar_startup_nrf52.s
 nrf.h
 nrf52_name_change.h
 system_nrf51422.c
-arm_startup_nrf51.s
-arm_startup_nrf52.s
 uicr_config.h
-iar_startup_nrf51.s
-iar_startup_nrf52.s
 
 # STM32CubeF4  - BSD License.
 stm32f4xx_hal_conf.h


[4/7] incubator-mynewt-core git commit: Add required notices for lwIP PPP files.

Posted by cc...@apache.org.
Add required notices for lwIP PPP files.

Various files in lwIP's PPP implementation require notices for the
contributions os the following people and organizations:

* Carnegie Mellon University
* Paul Mackerras
* Tommi Komulainen


Project: http://git-wip-us.apache.org/repos/asf/incubator-mynewt-core/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-mynewt-core/commit/4de64d19
Tree: http://git-wip-us.apache.org/repos/asf/incubator-mynewt-core/tree/4de64d19
Diff: http://git-wip-us.apache.org/repos/asf/incubator-mynewt-core/diff/4de64d19

Branch: refs/heads/1_0_0_b1_dev
Commit: 4de64d19c4a920104a940063b018cf29449ec0b8
Parents: e43eb6e
Author: Christopher Collins <cc...@apache.org>
Authored: Tue Nov 29 09:59:19 2016 -0800
Committer: Christopher Collins <cc...@apache.org>
Committed: Tue Nov 29 11:31:46 2016 -0800

----------------------------------------------------------------------
 NOTICE | 8 ++++++++
 1 file changed, 8 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-mynewt-core/blob/4de64d19/NOTICE
----------------------------------------------------------------------
diff --git a/NOTICE b/NOTICE
index 94bea73..87d40d5 100644
--- a/NOTICE
+++ b/NOTICE
@@ -6,3 +6,11 @@ The Apache Software Foundation (http://www.apache.org/).
 
 Portions of this software were developed at
 Runtime Inc, copyright 2015.
+
+This product includes software developed by Computing Services
+at Carnegie Mellon University (http://www.cmu.edu/computing/).
+
+This product includes software developed by Paul Mackerras <pa...@samba.org>.
+
+This product includes software developed by Tommi Komulainen
+<To...@iki.fi>.


[7/7] incubator-mynewt-core git commit: lwip_base - Add required mn_socket dependency.

Posted by cc...@apache.org.
lwip_base - Add required mn_socket dependency.


Project: http://git-wip-us.apache.org/repos/asf/incubator-mynewt-core/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-mynewt-core/commit/a3175ec5
Tree: http://git-wip-us.apache.org/repos/asf/incubator-mynewt-core/tree/a3175ec5
Diff: http://git-wip-us.apache.org/repos/asf/incubator-mynewt-core/diff/a3175ec5

Branch: refs/heads/1_0_0_b1_dev
Commit: a3175ec5948ac66a2277d5fcc7ccf52bda29e111
Parents: 01e8670
Author: Christopher Collins <cc...@apache.org>
Authored: Tue Nov 29 11:30:06 2016 -0800
Committer: Christopher Collins <cc...@apache.org>
Committed: Tue Nov 29 11:32:03 2016 -0800

----------------------------------------------------------------------
 net/ip/lwip_base/pkg.yml | 1 +
 1 file changed, 1 insertion(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-mynewt-core/blob/a3175ec5/net/ip/lwip_base/pkg.yml
----------------------------------------------------------------------
diff --git a/net/ip/lwip_base/pkg.yml b/net/ip/lwip_base/pkg.yml
index 27ea992..7941a76 100644
--- a/net/ip/lwip_base/pkg.yml
+++ b/net/ip/lwip_base/pkg.yml
@@ -29,6 +29,7 @@ pkg.keywords:
 
 pkg.deps:
     - net/ip
+    - net/ip/mn_socket
 
 pkg.cflags:
     - -Wno-unused-but-set-variable


[3/7] incubator-mynewt-core git commit: LICENSE/rat - Remove ptrs to unused libs

Posted by cc...@apache.org.
LICENSE/rat - Remove ptrs to unused libs

The following libraries are no longer in this repo therefore should not
be called out in LICENSE or .rat-excludes:
    * eLua
    * crc32


Project: http://git-wip-us.apache.org/repos/asf/incubator-mynewt-core/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-mynewt-core/commit/7ef94b8f
Tree: http://git-wip-us.apache.org/repos/asf/incubator-mynewt-core/tree/7ef94b8f
Diff: http://git-wip-us.apache.org/repos/asf/incubator-mynewt-core/diff/7ef94b8f

Branch: refs/heads/1_0_0_b1_dev
Commit: 7ef94b8f237bd5521dd4653e5f7e0296b77f5a13
Parents: 6bf8c36
Author: Christopher Collins <cc...@apache.org>
Authored: Tue Nov 29 09:06:09 2016 -0800
Committer: Christopher Collins <cc...@apache.org>
Committed: Tue Nov 29 11:31:46 2016 -0800

----------------------------------------------------------------------
 .rat-excludes |  6 ------
 LICENSE       | 14 --------------
 2 files changed, 20 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-mynewt-core/blob/7ef94b8f/.rat-excludes
----------------------------------------------------------------------
diff --git a/.rat-excludes b/.rat-excludes
index 551b4cd..ca1a212 100644
--- a/.rat-excludes
+++ b/.rat-excludes
@@ -159,9 +159,6 @@ stm32f4xx_hal_uart.c
 # klibc - MIT License.
 baselibc
 
-# eLua - MUT License.
-elua
-
 # CMSIS-CORE - BSD License.
 core_ca9.h
 core_caFunc.h
@@ -192,9 +189,6 @@ queue.h
 os_mbuf.c
 base64.c
 
-# crc32.c - Public domain.
-crc32.c
-
 # tinycrypt - BSD License.
 tinycrypt
 

http://git-wip-us.apache.org/repos/asf/incubator-mynewt-core/blob/7ef94b8f/LICENSE
----------------------------------------------------------------------
diff --git a/LICENSE b/LICENSE
index 6bff31e..b9da745 100644
--- a/LICENSE
+++ b/LICENSE
@@ -249,20 +249,6 @@ which are available under a BSD style license.  Relevant files are:
     * hw/bsp/nrf52pdk/nrf52pdk.ld
     * hw/bsp/nrf52pdk/nrf52pdk_no_boot.ld
 
-This product bundles Gary S. Brown's CRC32 implementation, which is available under the following license:
-    COPYRIGHT (C) 1986 Gary S. Brown.  You may use this program, or
-    code or tables extracted from it, as desired without restriction.
-
-This product bundles eLua, which is available under the MIT license.
-For details, see libs/elua/elua_base/
-
-eLua bundles further items which are available under permissive Apache
-compatable licenses (BSD/MIT). For full details see:
-libs/elua/elua_base/LICENSE
-
-This product bundles Lua-RPC library, which is available under a zlib license.
-for details see libs/elua/elua_base/LICENSE.luarpc
-
 This product bundles parts of CMSIS-CORE, which is available under the
 "3-clause BSD" license.  Bundled files are:
     * libs/cmsis-core/