-/* $OpenBSD: exec_elf.c,v 1.159 2021/03/08 05:57:34 deraadt Exp $ */
+/* $OpenBSD: exec_elf.c,v 1.160 2021/03/10 10:21:47 jsg Exp $ */
/*
* Copyright (c) 1996 Per Fogelstrom
elf_check_header(Elf_Ehdr *ehdr)
{
/*
- * We need to check magic, class size, endianess, and version before
+ * We need to check magic, class size, endianness, and version before
* we look at the rest of the Elf_Ehdr structure. These few elements
* are represented in a machine independent fashion.
*/
-/* $OpenBSD: kern_unveil.c,v 1.39 2020/03/22 20:23:36 anton Exp $ */
+/* $OpenBSD: kern_unveil.c,v 1.40 2021/03/10 10:21:47 jsg Exp $ */
/*
* Copyright (c) 2017-2019 Bob Beck <beck@openbsd.org>
/*
* XXX this will probably change.
- * XXX collapse down later once debug surely unneded
+ * XXX collapse down later once debug surely unneeded
*/
int
unveil_flagmatch(struct nameidata *ni, u_char flags)
return ENOENT;
}
- /* directry and flags match, update match */
+ /* directory and flags match, update match */
ni->ni_unveil_match = uv;
goto done;
}
-/* $OpenBSD: spec_vnops.c,v 1.102 2020/06/11 09:18:43 mpi Exp $ */
+/* $OpenBSD: spec_vnops.c,v 1.103 2021/03/10 10:21:47 jsg Exp $ */
/* $NetBSD: spec_vnops.c,v 1.29 1996/04/22 01:42:38 christos Exp $ */
/*
} else {
/*
* If the vnode is locked, then we are in the midst
- * of forcably closing the device, otherwise we only
+ * of forcibly closing the device, otherwise we only
* close on last reference.
*/
if (vcount(vp) > 1 && (vp->v_flag & VXLOCK) == 0)
-/* $OpenBSD: subr_hibernate.c,v 1.125 2018/06/21 07:49:13 mlarkin Exp $ */
+/* $OpenBSD: subr_hibernate.c,v 1.126 2021/03/10 10:21:47 jsg Exp $ */
/*
* Copyright (c) 2011 Ariane van der Steldt <ariane@stack.nl>
/*
* Initialize hiballoc.
*
- * The allocator will manage memmory at ptr, which is len bytes.
+ * The allocator will manage memory at ptr, which is len bytes.
*/
int
hiballoc_init(struct hiballoc_arena *arena, void *p_ptr, size_t p_len)
/*
* These mappings go into the resuming kernel's page table, and are
- * used only during image read. They dissappear from existence
+ * used only during image read. They disappear from existence
* when the suspended kernel is unpacked on top of us.
*/
tempva = (vaddr_t)km_alloc(MAXPHYS + PAGE_SIZE, &kv_any, &kp_none,
-/* $OpenBSD: subr_percpu.c,v 1.8 2017/09/08 05:36:53 deraadt Exp $ */
+/* $OpenBSD: subr_percpu.c,v 1.9 2021/03/10 10:21:47 jsg Exp $ */
/*
* Copyright (c) 2016 David Gwynne <dlg@openbsd.org>
struct cpumem *
counters_alloc_ncpus(struct cpumem *cm, unsigned int n)
{
- /* this is unecessary, but symmetrical */
+ /* this is unnecessary, but symmetrical */
return (cpumem_malloc_ncpus(cm, n * sizeof(uint64_t), M_COUNTERS));
}
-/* $OpenBSD: subr_pool.c,v 1.232 2021/01/06 07:51:40 claudio Exp $ */
+/* $OpenBSD: subr_pool.c,v 1.233 2021/03/10 10:21:47 jsg Exp $ */
/* $NetBSD: subr_pool.c,v 1.61 2001/09/26 07:14:56 chs Exp $ */
/*-
pool_init(&phpool, sizeof(struct pool_page_header), 0,
IPL_HIGH, 0, "phpool", NULL);
- /* make sure phpool wont "recurse" */
+ /* make sure phpool won't "recurse" */
KASSERT(POOL_INPGHDR(&phpool));
}
if (v != NULL && POOL_INPGHDR(pp)) {
vaddr_t addr = (vaddr_t)v;
if ((addr & pp->pr_pgmask) != addr) {
- panic("%s: %s page address %p isnt aligned to %u",
+ panic("%s: %s page address %p isn't aligned to %u",
__func__, pp->pr_wchan, v, pp->pr_pgsize);
}
}
-/* $OpenBSD: subr_witness.c,v 1.45 2021/02/08 10:51:02 mpi Exp $ */
+/* $OpenBSD: subr_witness.c,v 1.46 2021/03/10 10:21:47 jsg Exp $ */
/*-
* Copyright (c) 2008 Isilon Systems, Inc.
}
/*
- * Checks if @descendant is a direct or inderect descendant of @ancestor.
+ * Checks if @descendant is a direct or indirect descendant of @ancestor.
*/
static int
isitmydescendant(struct witness *ancestor, struct witness *descendant)
-/* $OpenBSD: sys_futex.c,v 1.16 2020/04/06 02:44:31 cheloha Exp $ */
+/* $OpenBSD: sys_futex.c,v 1.17 2021/03/10 10:21:47 jsg Exp $ */
/*
* Copyright (c) 2016-2017 Martin Pieuchot
/*
* Put the current thread on the sleep queue of the futex at address
* ``uaddr''. Let it sleep for the specified ``timeout'' time, or
- * indefinitly if the argument is NULL.
+ * indefinitely if the argument is NULL.
*/
int
futex_wait(uint32_t *uaddr, uint32_t val, const struct timespec *timeout,
if (error == ERESTART)
error = ECANCELED;
else if (error == EWOULDBLOCK) {
- /* A race occured between a wakeup and a timeout. */
+ /* A race occurred between a wakeup and a timeout. */
if (p->p_futex == NULL)
error = 0;
else
-/* $OpenBSD: tty_tty.c,v 1.27 2020/06/11 09:18:43 mpi Exp $ */
+/* $OpenBSD: tty_tty.c,v 1.28 2021/03/10 10:21:47 jsg Exp $ */
/* $NetBSD: tty_tty.c,v 1.13 1996/03/30 22:24:46 christos Exp $ */
/*-
case TIOCCHKVERAUTH:
/*
* It's not clear when or what these checks are for.
- * How can we reach this code with a differnt ruid?
+ * How can we reach this code with a different ruid?
* The ppid check is also more porous than desired.
* Nevertheless, the checks reflect the original intention;
* namely, that it be the same user using the same shell.
-/* $OpenBSD: vfs_bio.c,v 1.204 2020/10/05 01:56:17 asou Exp $ */
+/* $OpenBSD: vfs_bio.c,v 1.205 2021/03/10 10:21:47 jsg Exp $ */
/* $NetBSD: vfs_bio.c,v 1.44 1996/06/11 11:15:36 pk Exp $ */
/*
KASSERT(bp->b_bufsize > 0);
/*
- * softdep is basically incompatible with not cacheing buffers
+ * softdep is basically incompatible with not caching buffers
* that have dependencies, so this buffer must be cached
*/
if (LIST_FIRST(&bp->b_dep) != NULL)
* This implementation adds support for multiple 2q caches.
*
* If we have more than one 2q cache, as bufs fall off the cold queue
- * for recyclying, bufs that have been warm before (which retain the
+ * for recycling, bufs that have been warm before (which retain the
* B_WARM flag in addition to B_COLD) can be put into the hot queue of
* a second level 2Q cache. buffers which are only B_COLD are
* recycled. Bufs falling off the last cache's cold queue are always
-/* $OpenBSD: bridgestp.c,v 1.76 2021/01/25 19:47:16 mvs Exp $ */
+/* $OpenBSD: bridgestp.c,v 1.77 2021/03/10 10:21:47 jsg Exp $ */
/*
* Copyright (c) 2000 Jason L. Wright (jason@thought.net)
/* convert seconds to ticks */
val *= BSTP_TICK_VAL;
- /* value can only be changed in leagacy stp mode */
+ /* value can only be changed in legacy stp mode */
if (bs->bs_protover != BSTP_PROTO_STP) {
err = EPERM;
break;
-/* $OpenBSD: ethertypes.h,v 1.13 2019/10/29 03:19:16 dlg Exp $ */
+/* $OpenBSD: ethertypes.h,v 1.14 2021/03/10 10:21:47 jsg Exp $ */
/* $NetBSD: ethertypes.h,v 1.13 2002/02/10 01:28:32 thorpej Exp $ */
/*
#define ETHERTYPE_NBPVCD 0x3C00 /* 3Com NBP virtual circuit datagram (like XNS SPP) not registered */
#define ETHERTYPE_NBPSCD 0x3C01 /* 3Com NBP System control datagram not registered */
#define ETHERTYPE_NBPCREQ 0x3C02 /* 3Com NBP Connect request (virtual cct) not registered */
-#define ETHERTYPE_NBPCRSP 0x3C03 /* 3Com NBP Connect repsonse not registered */
+#define ETHERTYPE_NBPCRSP 0x3C03 /* 3Com NBP Connect response not registered */
#define ETHERTYPE_NBPCC 0x3C04 /* 3Com NBP Connect complete not registered */
#define ETHERTYPE_NBPCLREQ 0x3C05 /* 3Com NBP Close request (virtual cct) not registered */
#define ETHERTYPE_NBPCLRSP 0x3C06 /* 3Com NBP Close response not registered */
-/* $OpenBSD: if.c,v 1.633 2021/03/09 20:03:50 anton Exp $ */
+/* $OpenBSD: if.c,v 1.634 2021/03/10 10:21:47 jsg Exp $ */
/* $NetBSD: if.c,v 1.35 1996/05/07 05:26:04 thorpej Exp $ */
/*
* the stack assumes that an interface can have multiple
* transmit rings, but a lot of drivers are still written
* so that interfaces and send rings have a 1:1 mapping.
- * this provides compatability between the stack and the older
+ * this provides compatibility between the stack and the older
* drivers by translating from the only queue they have
* (ifp->if_snd) back to the interface and calling if_start.
*/
-/* $OpenBSD: if_bridge.h,v 1.71 2021/01/25 19:47:16 mvs Exp $ */
+/* $OpenBSD: if_bridge.h,v 1.72 2021/03/10 10:21:47 jsg Exp $ */
/*
* Copyright (c) 1999, 2000 Jason L. Wright (jason@thought.net)
struct ether_addr brl_dst; /* destination mac address */
u_int16_t brl_tag; /* pf tag ID */
u_int8_t brl_action; /* what to do with match */
- u_int8_t brl_flags; /* comparision flags */
+ u_int8_t brl_flags; /* comparison flags */
struct ifbrarpf brl_arpf; /* arp filter */
};
-/* $OpenBSD: if_etherbridge.c,v 1.5 2021/02/26 08:31:23 dlg Exp $ */
+/* $OpenBSD: if_etherbridge.c,v 1.6 2021/03/10 10:21:47 jsg Exp $ */
/*
* Copyright (c) 2018, 2021 David Gwynne <dlg@openbsd.org>
if (nebe != NULL) {
/*
- * the new entry didnt make it into the
+ * the new entry didn't make it into the
* table, so it can be freed directly.
*/
ebe_free(nebe);
if (error != 0) {
/*
- * the new entry didnt make it into the
+ * the new entry didn't make it into the
* table, so it can be freed directly.
*/
ebe_free(nebe);
-/* $OpenBSD: if_gre.c,v 1.170 2021/02/27 09:21:22 dlg Exp $ */
+/* $OpenBSD: if_gre.c,v 1.171 2021/03/10 10:21:47 jsg Exp $ */
/* $NetBSD: if_gre.c,v 1.9 1999/10/25 19:18:11 drochner Exp $ */
/*
rt = rt_getll(rt0);
- /* chech rt_expire? */
+ /* check rt_expire? */
if (ISSET(rt->rt_flags, RTF_REJECT)) {
error = (rt == rt0) ? EHOSTDOWN : EHOSTUNREACH;
goto drop;
uint8_t tos;
/*
- * re-schedule immediately, so we deal with incomplete configuation
+ * re-schedule immediately, so we deal with incomplete configuration
* or temporary errors.
*/
if (sc->sc_ka_timeo)
-/* $OpenBSD: if_gre.h,v 1.15 2018/02/07 22:30:59 dlg Exp $ */
+/* $OpenBSD: if_gre.h,v 1.16 2021/03/10 10:21:48 jsg Exp $ */
/* $NetBSD: if_gre.h,v 1.5 1999/11/19 20:41:19 thorpej Exp $ */
/*
u_int_32 seq_num Sequence number to allow for packet order
Present if (seq_pres ==1 ).
- struct gre_sre[] routing Routing fileds (see below)
+ struct gre_sre[] routing Routing fields (see below)
Present if (rt_pres == 1)
*/
} __packed;
-/* $OpenBSD: if_pfsync.c,v 1.287 2021/02/25 02:48:21 dlg Exp $ */
+/* $OpenBSD: if_pfsync.c,v 1.288 2021/03/10 10:21:48 jsg Exp $ */
/*
* Copyright (c) 2002 Michael Shalayeff
pfsync_q_del(st);
/*
* FALLTHROUGH to putting it on the del list
- * Note on refence count bookeeping:
+ * Note on reference count bookkeeping:
* pfsync_q_del() drops reference for queue
* ownership. But the st entry survives, because
* our caller still holds a reference.
-/* $OpenBSD: if_pfsync.h,v 1.55 2021/02/04 00:55:41 sashan Exp $ */
+/* $OpenBSD: if_pfsync.h,v 1.56 2021/03/10 10:21:48 jsg Exp $ */
/*
* Copyright (c) 2001 Michael Shalayeff
#define PFSYNC_ACT_CLR 0 /* clear all states */
#define PFSYNC_ACT_OINS 1 /* old insert state */
-#define PFSYNC_ACT_INS_ACK 2 /* ack of insterted state */
+#define PFSYNC_ACT_INS_ACK 2 /* ack of inserted state */
#define PFSYNC_ACT_OUPD 3 /* old update state */
#define PFSYNC_ACT_UPD_C 4 /* "compressed" update state */
#define PFSYNC_ACT_UPD_REQ 5 /* request "uncompressed" state */
-/* $OpenBSD: if_sppp.h,v 1.27 2019/06/24 21:36:53 kn Exp $ */
+/* $OpenBSD: if_sppp.h,v 1.28 2021/03/10 10:21:48 jsg Exp $ */
/* $NetBSD: if_sppp.h,v 1.2.2.1 1999/04/04 06:57:39 explorer Exp $ */
/*
/*
* Don't change the order of this. Ordering the phases this way allows
- * for a comparision of ``pp_phase >= PHASE_AUTHENTICATE'' in order to
+ * for a comparison of ``pp_phase >= PHASE_AUTHENTICATE'' in order to
* know whether LCP is up.
*/
enum ppp_phase {
-/* $OpenBSD: if_types.h,v 1.22 2020/06/21 11:25:54 dlg Exp $ */
+/* $OpenBSD: if_types.h,v 1.23 2021/03/10 10:21:48 jsg Exp $ */
/* $NetBSD: if_types.h,v 1.17 2000/10/26 06:51:31 onoe Exp $ */
/*
#define IFT_SIPSIG 0xcc /* SIP Signaling */
#define IFT_DOCSCABLEUPSTREAMCHANNEL 0xcd /* CATV Upstream Channel */
#define IFT_ECONET 0xce /* Acorn Econet */
-#define IFT_PON155 0xcf /* FSAN 155Mb Symetrical PON interface */
-#define IFT_PON622 0xd0 /* FSAN 622Mb Symetrical PON interface */
+#define IFT_PON155 0xcf /* FSAN 155Mb Symmetrical PON interface */
+#define IFT_PON622 0xd0 /* FSAN 622Mb Symmetrical PON interface */
#define IFT_BRIDGE 0xd1 /* Transparent bridge interface */
#define IFT_LINEGROUP 0xd2 /* Interface common to multiple lines */
#define IFT_VOICEEMFGD 0xd3 /* voice E&M Feature Group D */
-/* $OpenBSD: if_veb.c,v 1.15 2021/03/05 06:44:09 dlg Exp $ */
+/* $OpenBSD: if_veb.c,v 1.16 2021/03/10 10:21:48 jsg Exp $ */
/*
* Copyright (c) 2021 David Gwynne <dlg@openbsd.org>
#if NPF > 0
/*
- * we couldnt find a specific port to send this packet to,
+ * we couldn't find a specific port to send this packet to,
* but pf should still have a chance to apply policy to it.
* let pf look at it, but use the veb interface as a proxy.
*/
-/* $OpenBSD: if_wg.c,v 1.15 2021/01/25 09:11:36 yasuoka Exp $ */
+/* $OpenBSD: if_wg.c,v 1.16 2021/03/10 10:21:48 jsg Exp $ */
/*
* Copyright (C) 2015-2020 Jason A. Donenfeld <Jason@zx2c4.com>. All Rights Reserved.
/*
* The following section handles the timeout callbacks for a WireGuard session.
- * These functions provide an "event based" model for controling wg(8) session
+ * These functions provide an "event based" model for controlling wg(8) session
* timers. All function calls occur after the specified event below.
*
* wg_timers_event_data_sent:
-/* $OpenBSD: ifq.h,v 1.32 2020/07/07 00:00:03 dlg Exp $ */
+/* $OpenBSD: ifq.h,v 1.33 2021/03/10 10:21:48 jsg Exp $ */
/*
* Copyright (c) 2015 David Gwynne <dlg@openbsd.org>
*
* === ifq_mfreem() and ifq_mfreeml()
*
- * A goal of the API is to avoid freeing an mbuf while mutexs are
+ * A goal of the API is to avoid freeing an mbuf while mutexes are
* held. Because the ifq API manages the lock on behalf of the backend
* ifqops, the backend should not directly free mbufs. If a conditioner
* backend needs to drop a packet during the handling of ifqop_deq_begin,
-/* $OpenBSD: ofp.h,v 1.13 2016/12/02 17:10:20 rzalamena Exp $ */
+/* $OpenBSD: ofp.h,v 1.14 2021/03/10 10:21:48 jsg Exp $ */
/*
* Copyright (c) 2013-2016 Reyk Floeter <reyk@openbsd.org>
#define OFP_ACTION_POP_VLAN 18 /* Pop the outer VLAN tag */
#define OFP_ACTION_PUSH_MPLS 19 /* Push a new MPLS tag */
#define OFP_ACTION_POP_MPLS 20 /* Pop the outer MPLS tag */
-#define OFP_ACTION_SET_QUEUE 21 /* Set queue id when outputing to a port */
+#define OFP_ACTION_SET_QUEUE 21 /* Set queue id when outputting to a port */
#define OFP_ACTION_GROUP 22 /* Apply group */
#define OFP_ACTION_SET_NW_TTL 23 /* Set IP TTL */
#define OFP_ACTION_DEC_NW_TTL 24 /* Decrement IP TTL */
-/* $OpenBSD: pf.c,v 1.1113 2021/03/01 11:05:42 bluhm Exp $ */
+/* $OpenBSD: pf.c,v 1.1114 2021/03/10 10:21:48 jsg Exp $ */
/*
* Copyright (c) 2001 Daniel Hartmeier
} else {
rv = pf_match_rule(ctx, &r->anchor->ruleset);
/*
- * Unless errors occured, stop iff any rule matched
+ * Unless errors occurred, stop iff any rule matched
* within quick anchors.
*/
if (rv != PF_TEST_FAIL && r->quick == PF_TEST_QUICK &&
-/* $OpenBSD: pf_norm.c,v 1.222 2021/03/01 11:05:42 bluhm Exp $ */
+/* $OpenBSD: pf_norm.c,v 1.223 2021/03/10 10:21:48 jsg Exp $ */
/*
* Copyright 2001 Niels Provos <provos@citi.umich.edu>
}
if (copyback) {
- /* Copyback the options, caller copys back header */
+ /* Copyback the options, caller copies back header */
*writeback = 1;
m_copyback(pd->m, pd->off + sizeof(*th), olen, opts, M_NOWAIT);
}
-/* $OpenBSD: pfvar.h,v 1.499 2021/02/01 00:31:05 dlg Exp $ */
+/* $OpenBSD: pfvar.h,v 1.500 2021/03/10 10:21:48 jsg Exp $ */
/*
* Copyright (c) 2001 Daniel Hartmeier
/*
* The number of entries in the fragment queue must be limited
- * to avoid DoS by linear seaching. Instead of a global limit,
+ * to avoid DoS by linear searching. Instead of a global limit,
* use a limit per entry point. For large packets these sum up.
*/
#define PF_FRAG_ENTRY_LIMIT 64
-/* $OpenBSD: pipex.c,v 1.131 2021/02/25 02:48:21 dlg Exp $ */
+/* $OpenBSD: pipex.c,v 1.132 2021/03/10 10:21:48 jsg Exp $ */
/*-
* Copyright (c) 2009 Internet Initiative Japan Inc.
/*
* create a deep-copy if the mbuf has a shared mbuf cluster.
- * this is required to handle cases of tcp retransmition.
+ * this is required to handle cases of tcp retransmission.
*/
for (m = m0; m != NULL; m = m->m_next) {
if (M_READONLY(m)) {
}
#endif
/***********************************************************************
- * Miscellaneous fuctions
+ * Miscellaneous functions
***********************************************************************/
/* adapted from FreeBSD:src/usr.sbin/ppp/tcpmss.c */
/*
-/* $OpenBSD: radix.c,v 1.59 2019/07/08 17:49:57 mpi Exp $ */
+/* $OpenBSD: radix.c,v 1.60 2021/03/10 10:21:48 jsg Exp $ */
/* $NetBSD: radix.c,v 1.20 2003/08/07 16:32:56 agc Exp $ */
/*
"inconsistent mklist refcount\n");
}
/*
- * If we end up here tt should be m->rm_leaf and therefor
+ * If we end up here tt should be m->rm_leaf and therefore
* tt should be the head of a multipath chain.
* If this is not the case the table is no longer consistent.
*/
-/* $OpenBSD: route.c,v 1.397 2020/10/29 21:15:27 denis Exp $ */
+/* $OpenBSD: route.c,v 1.398 2021/03/10 10:21:48 jsg Exp $ */
/* $NetBSD: route.c,v 1.14 1996/02/13 22:00:46 christos Exp $ */
/*
rt->rt_mtu = nhrt->rt_mtu;
/*
- * To avoid reference counting problems when writting link-layer
+ * To avoid reference counting problems when writing link-layer
* addresses in an outgoing packet, we ensure that the lifetime
* of a cached entry is greater than the bigger lifetime of the
* gateway entries it is pointed by.
}
/*
- * Remove local rtentry of ifa's addresss if it exists.
+ * Remove local rtentry of ifa's address if it exists.
*/
int
rt_ifa_dellocal(struct ifaddr *ifa)
-/* $OpenBSD: route.h,v 1.183 2020/10/29 21:15:27 denis Exp $ */
+/* $OpenBSD: route.h,v 1.184 2021/03/10 10:21:48 jsg Exp $ */
/* $NetBSD: route.h,v 1.9 1996/02/13 22:00:49 christos Exp $ */
/*
/*
* setsockopt defines used for the filtering.
*/
-#define ROUTE_MSGFILTER 1 /* bitmask to specifiy which types should be
+#define ROUTE_MSGFILTER 1 /* bitmask to specify which types should be
sent to the client. */
#define ROUTE_TABLEFILTER 2 /* change routing table the socket is listening
on, RTABLE_ANY listens on all tables. */
-/* $OpenBSD: rtable.c,v 1.72 2020/11/07 09:51:40 denis Exp $ */
+/* $OpenBSD: rtable.c,v 1.73 2021/03/10 10:21:48 jsg Exp $ */
/*
* Copyright (c) 2014-2016 Martin Pieuchot
struct rtmap *map = xmap;
/*
- * doesnt need to be serialized since this is the last reference
+ * doesn't need to be serialized since this is the last reference
* to this map. there's nothing to race against.
*/
free(map->tbl, M_RTABLE, map->limit * sizeof(*map[0].tbl));
-/* $OpenBSD: switchofp.c,v 1.79 2021/02/25 02:48:21 dlg Exp $ */
+/* $OpenBSD: switchofp.c,v 1.80 2021/03/10 10:21:48 jsg Exp $ */
/*
* Copyright (c) 2016 Kazuya GODA <goda@openbsd.org>
LIST_FOREACH_SAFE(swfe, &swft->swft_flow_list, swfe_next, tswfe) {
/*
- * Flows are deleted force becouse of deleting table,
+ * Flows are deleted force because of deleting table,
* s it's not necessary to send flow remove message.
*/
swfe->swfe_flags &= ~(OFP_FLOWFLAG_SEND_FLOW_REMOVED);
switch (OFP_OXM_GET_FIELD(oxm)) {
case OFP_XM_T_IN_PORT:
/*
- * in_port isn't network byte order becouse
+ * in_port isn't network byte order because
* it's pipeline match field.
*/
in = htonl(swfcl->swfcl_in_port);
* splited some OpenFlow messages. OpenFlow Switch Specification says that
* "NO OBJECT CAN BE SPLIT ACROSS TWO MESSAGES". In other words, point of
* splittig is different per reply, so switch(4) builds multipart message using
- * swofp_mpms_* functions which splits messsages not to object across
+ * swofp_mpms_* functions which splits messages not to object across
* two messages.
*/
int
}
/*
- * It's always 4 byte for padding becouse struct ofp_ox_mach and
+ * It's always 4 byte for padding because struct ofp_ox_mach and
* struct ofp_table_feature_property are 4 byte.
*/
if ((supported & 0x1) == 0) {
goto error;
TAILQ_FOREACH(swft, &ofs->swofs_table_list, swft_table_next) {
- /* using mbuf becouse table featrues struct is variable length*/
+ /* using mbuf because table features struct is variable length*/
MGETHDR(n, M_DONTWAIT, MT_DATA);
if (n == NULL)
goto error;
-/* $OpenBSD: wg_cookie.c,v 1.2 2020/12/09 05:53:33 tb Exp $ */
+/* $OpenBSD: wg_cookie.c,v 1.3 2021/03/10 10:21:48 jsg Exp $ */
/*
* Copyright (C) 2015-2020 Jason A. Donenfeld <Jason@zx2c4.com>. All Rights Reserved.
* Copyright (C) 2019-2020 Matt Dunwoodie <ncon@noconroy.net>
cookie_macs_mac1(&our_cm, buf, len, cc->cc_mac1_key);
rw_exit_read(&cc->cc_key_lock);
- /* If mac1 is invald, we want to drop the packet */
+ /* If mac1 is invalid, we want to drop the packet */
if (timingsafe_bcmp(our_cm.mac1, cm->mac1, COOKIE_MAC_SIZE) != 0)
return EINVAL;
-/* $OpenBSD: ieee80211_crypto_tkip.c,v 1.32 2020/07/15 22:49:07 cheloha Exp $ */
+/* $OpenBSD: ieee80211_crypto_tkip.c,v 1.33 2021/03/10 10:21:48 jsg Exp $ */
/*-
* Copyright (c) 2008 Damien Bergamini <damien.bergamini@free.fr>
/*
* Compute TKIP MIC over an mbuf chain starting "off" bytes from the
- * beginning. This function should be kept independant from the software
+ * beginning. This function should be kept independent from the software
* TKIP crypto code so that drivers doing hardware crypto but not MIC can
* call it without a software crypto context.
*/
}
/*
- * Get the frame's Tansmit Sequence Counter (TSC), and a pointer to
+ * Get the frame's Transmit Sequence Counter (TSC), and a pointer to
* our last-seen Receive Sequence Counter (RSC) with which we can
* detect replays.
*/
-/* $OpenBSD: ieee80211_input.c,v 1.228 2020/12/10 12:52:49 stsp Exp $ */
+/* $OpenBSD: ieee80211_input.c,v 1.229 2021/03/10 10:21:48 jsg Exp $ */
/*-
* Copyright (c) 2001 Atsushi Onoe
if (count > ba->ba_winsize) {
/*
* Check whether we're consistently behind the window,
- * and let the window move forward if neccessary.
+ * and let the window move forward if necessary.
*/
if (ba->ba_winmiss < IEEE80211_BA_MAX_WINMISS) {
if (ba->ba_missedsn == ((sn - 1) & 0xfff))
rsn->rsn_groupcipher = IEEE80211_CIPHER_CCMP;
rsn->rsn_nciphers = 1;
rsn->rsn_ciphers = IEEE80211_CIPHER_CCMP;
- /* if Group Management Cipher Suite missing, defaut to BIP */
+ /* if Group Management Cipher Suite missing, default to BIP */
rsn->rsn_groupmgmtcipher = IEEE80211_CIPHER_BIP;
/* if AKM Suite missing, default to 802.1X */
rsn->rsn_nakms = 1;
-/* $OpenBSD: ieee80211_node.c,v 1.182 2020/05/31 09:08:33 stsp Exp $ */
+/* $OpenBSD: ieee80211_node.c,v 1.183 2021/03/10 10:21:48 jsg Exp $ */
/* $NetBSD: ieee80211_node.c,v 1.14 2004/05/09 09:18:47 dyoung Exp $ */
/*-
ni = ieee80211_alloc_node_helper(ic);
if (ni == NULL)
- panic("unable to setup inital BSS node");
+ panic("unable to setup initial BSS node");
ni->ni_chan = IEEE80211_CHAN_ANYC;
ic->ic_bss = ieee80211_ref_node(ni);
ic->ic_txpower = IEEE80211_TXPOWER_MAX;
-/* $OpenBSD: ieee80211_output.c,v 1.132 2020/12/08 15:52:04 stsp Exp $ */
+/* $OpenBSD: ieee80211_output.c,v 1.133 2021/03/10 10:21:48 jsg Exp $ */
/* $NetBSD: ieee80211_output.c,v 1.13 2004/05/31 11:02:55 dyoung Exp $ */
/*-
/*
* Don't use A-MPDU on non-encrypted networks. There are devices
* with buggy firmware which allow an attacker to inject 802.11
- * frames into a wifi network by embedding rouge A-MPDU subframes
+ * frames into a wifi network by embedding rogue A-MPDU subframes
* in an arbitrary data payload (e.g. PNG images) which may end
* up appearing as actual frames after de-aggregation by a buggy
* device; see https://github.com/rpp0/aggr-inject for details.
}
/*-
- * SA Query Request/Reponse frame format:
+ * SA Query Request/Response frame format:
* [1] Category
* [1] Action
* [16] Transaction Identifier
-/* $OpenBSD: if_ether.h,v 1.80 2021/03/05 06:44:09 dlg Exp $ */
+/* $OpenBSD: if_ether.h,v 1.81 2021/03/10 10:21:48 jsg Exp $ */
/* $NetBSD: if_ether.h,v 1.22 1996/05/11 13:00:00 mycroft Exp $ */
/*
#define ETHERMIN (ETHER_MIN_LEN - ETHER_HDR_LEN - ETHER_CRC_LEN)
/*
- * Ethernet CRC32 polynomials (big- and little-endian verions).
+ * Ethernet CRC32 polynomials (big- and little-endian versions).
*/
#define ETHER_CRC_POLY_LE 0xedb88320
#define ETHER_CRC_POLY_BE 0x04c11db6
-/* $OpenBSD: in.c,v 1.170 2020/05/27 11:19:28 mpi Exp $ */
+/* $OpenBSD: in.c,v 1.171 2021/03/10 10:21:48 jsg Exp $ */
/* $NetBSD: in.c,v 1.26 1996/02/13 23:41:39 christos Exp $ */
/*
/*
* Add the address to the local list and the global tree. If an
- * error occured, put back the original address.
+ * error occurred, put back the original address.
*/
ifa_add(ifp, &ia->ia_ifa);
rterror = rt_ifa_addlocal(&ia->ia_ifa);
-/* $OpenBSD: in_pcb.c,v 1.254 2021/02/11 10:41:19 patrick Exp $ */
+/* $OpenBSD: in_pcb.c,v 1.255 2021/03/10 10:21:48 jsg Exp $ */
/* $NetBSD: in_pcb.c,v 1.25 1996/02/13 23:41:53 christos Exp $ */
/*
/*
* Use preferred source address if :
* - destination is not onlink
- * - preferred source addresss is set
+ * - preferred source address is set
* - output interface is UP
*/
if (ro->ro_rt && !(ro->ro_rt->rt_flags & RTF_LLINFO) &&
-/* $OpenBSD: ip_carp.c,v 1.353 2021/03/07 06:02:32 dlg Exp $ */
+/* $OpenBSD: ip_carp.c,v 1.354 2021/03/10 10:21:48 jsg Exp $ */
/*
* Copyright (c) 2002 Michael Shalayeff. All rights reserved.
/*
* Do not leak the multicast address when sending
- * advertisements in 'ip' and 'ip-stealth' balacing
+ * advertisements in 'ip' and 'ip-stealth' balancing
* modes.
*/
if (sc->sc_balancing == CARP_BAL_IP ||
-/* $OpenBSD: ip_id.c,v 1.24 2014/11/18 02:37:31 tedu Exp $ */
+/* $OpenBSD: ip_id.c,v 1.25 2021/03/10 10:21:48 jsg Exp $ */
/*
* Copyright (c) 2008 Theo de Raadt, Ryan McBride
/*
* Return a random IP id. Shuffle the new value we get into the previous half
* of the ip_shuffle ring (-32767 or swap with ourself), to avoid duplicates
- * occuring too quickly but also still be random.
+ * occurring too quickly but also still be random.
*
* 0 is a special IP ID -- don't return it.
*/
-/* $OpenBSD: ip_input.c,v 1.354 2021/01/15 15:18:12 bluhm Exp $ */
+/* $OpenBSD: ip_input.c,v 1.355 2021/03/10 10:21:48 jsg Exp $ */
/* $NetBSD: ip_input.c,v 1.30 1996/03/16 23:53:58 christos Exp $ */
/*
*offp = hlen;
nxt = ip->ip_p;
- /* Check wheter we are already in a IPv4/IPv6 local deliver loop. */
+ /* Check whether we are already in a IPv4/IPv6 local deliver loop. */
if (af == AF_UNSPEC)
nxt = ip_deliver(mp, offp, nxt, AF_INET);
return nxt;
-/* $OpenBSD: ip_ipsp.c,v 1.237 2021/02/23 19:43:54 tobhe Exp $ */
+/* $OpenBSD: ip_ipsp.c,v 1.238 2021/03/10 10:21:49 jsg Exp $ */
/*
* The authors of this code are John Ioannidis (ji@tla.org),
* Angelos D. Keromytis (kermit@csd.uch.gr),
/*
* Rehash if this tdb would cause a bucket to have more than
* two items and if the number of tdbs exceed 10% of the
- * bucket count. This number is arbitratily chosen and is
+ * bucket count. This number is arbitrarily chosen and is
* just a measure to not keep rehashing when adding and
* removing tdbs which happens to always end up in the same
* bucket, which is not uncommon when doing manual keying.
-/* $OpenBSD: ipsec_output.c,v 1.78 2020/09/22 19:20:21 tobhe Exp $ */
+/* $OpenBSD: ipsec_output.c,v 1.79 2021/03/10 10:21:49 jsg Exp $ */
/*
* The author of this code is Angelos D. Keromytis (angelos@cis.upenn.edu)
*
dstopt = 1;
} else if (nxt == IPPROTO_ROUTING) {
/*
- * if we see destionation option next
+ * if we see destination option next
* time, it must be dest2.
*/
dstopt = 2;
-/* $OpenBSD: tcp_input.c,v 1.366 2021/02/03 13:40:06 jan Exp $ */
+/* $OpenBSD: tcp_input.c,v 1.367 2021/03/10 10:21:49 jsg Exp $ */
/* $NetBSD: tcp_input.c,v 1.23 1996/02/13 23:43:44 christos Exp $ */
/*
* If there are no entries in the hash table, reinitialize
* the hash secrets. To avoid useless cache swaps and
* reinitialization, use it until the limit is reached.
- * An emtpy cache is also the oportunity to resize the hash.
+ * An empty cache is also the opportunity to resize the hash.
*/
if (set->scs_count == 0 && set->scs_use <= 0) {
set->scs_use = tcp_syn_use_limit;
NET_ASSERT_LOCKED();
- /* Check the active cache first, the passive cache is likely emtpy. */
+ /* Check the active cache first, the passive cache is likely empty. */
sets[0] = &tcp_syn_cache[tcp_syn_cache_active];
sets[1] = &tcp_syn_cache[!tcp_syn_cache_active];
for (i = 0; i < 2; i++) {
tp->rcv_up = sc->sc_irs + 1;
/*
- * This is what whould have happened in tcp_output() when
+ * This is what would have happened in tcp_output() when
* the SYN,ACK was sent.
*/
tp->snd_up = tp->snd_una;
* With the default sbmax of 256K, a scale factor
* of 3 will be chosen by this algorithm. Those who
* choose a larger sbmax should watch out
- * for the compatiblity problems mentioned above.
+ * for the compatibility problems mentioned above.
*
* RFC1323: The Window field in a SYN (i.e., a <SYN>
* or <SYN,ACK>) segment itself is never scaled.
-/* $OpenBSD: tcp_usrreq.c,v 1.179 2021/01/09 20:58:37 gnezdo Exp $ */
+/* $OpenBSD: tcp_usrreq.c,v 1.180 2021/03/10 10:21:49 jsg Exp $ */
/* $NetBSD: tcp_usrreq.c,v 1.20 1996/02/13 23:44:16 christos Exp $ */
/*
/*
* Scale the send buffer so that inflight data is not accounted against
* the limit. The buffer will scale with the congestion window, if the
- * the receiver stops acking data the window will shrink and therefor
+ * the receiver stops acking data the window will shrink and therefore
* the buffer size will shrink as well.
* In low memory situation try to shrink the buffer to the initial size
* disabling the send buffer scaling as long as the situation persists.
-/* $OpenBSD: icmp6.c,v 1.234 2021/01/11 13:28:53 bluhm Exp $ */
+/* $OpenBSD: icmp6.c,v 1.235 2021/03/10 10:21:49 jsg Exp $ */
/* $KAME: icmp6.c,v 1.217 2001/06/20 15:03:29 jinmei Exp $ */
/*
/*
* icmp6_reflect() is designed to be in the input path.
- * icmp6_error() can be called from both input and outut path,
+ * icmp6_error() can be called from both input and output path,
* and if we are in output path rcvif could contain bogus value.
* clear m->m_pkthdr.ph_ifidx for safety, we should have enough
* scope information in ip header (nip6).
freeit:
/*
- * If we can't tell wheter or not we can generate ICMP6, free it.
+ * If we can't tell whether or not we can generate ICMP6, free it.
*/
return (m_freem(m));
}
-/* $OpenBSD: in6.c,v 1.242 2020/08/07 18:09:16 florian Exp $ */
+/* $OpenBSD: in6.c,v 1.243 2021/03/10 10:21:49 jsg Exp $ */
/* $KAME: in6.c,v 1.372 2004/06/14 08:14:21 itojun Exp $ */
/*
IN6_LOOKUP_MULTI(*maddr6, ifp, in6m);
if (in6m != NULL) {
/*
- * Found it; just increment the refrence count.
+ * Found it; just increment the reference count.
*/
in6m->in6m_refcnt++;
} else {
}
imm->i6mm_maddr = in6_addmulti(addr, ifp, errorp);
if (!imm->i6mm_maddr) {
- /* *errorp is alrady set */
+ /* *errorp is already set */
free(imm, M_IPMADDR, sizeof(*imm));
return NULL;
}
/*
* Our DAD routine requires the interface up and running.
* However, some interfaces can be up before the RUNNING
- * status. Additionaly, users may try to assign addresses
+ * status. Additionally, users may try to assign addresses
* before the interface becomes up (or running).
* We simply skip DAD in such a case as a work around.
* XXX: we should rather mark "tentative" on such addresses,
-/* $OpenBSD: in6.h,v 1.107 2020/08/24 16:40:07 gnezdo Exp $ */
+/* $OpenBSD: in6.h,v 1.108 2021/03/10 10:21:49 jsg Exp $ */
/* $KAME: in6.h,v 1.83 2001/03/29 02:55:07 jinmei Exp $ */
/*
#define IPV6_HOPLIMIT 47 /* int; send hop limit */
#define IPV6_NEXTHOP 48 /* sockaddr; next hop addr */
#define IPV6_HOPOPTS 49 /* ip6_hbh; send hop-by-hop option */
-#define IPV6_DSTOPTS 50 /* ip6_dest; send dst option befor rthdr */
+#define IPV6_DSTOPTS 50 /* ip6_dest; send dst option before rthdr */
#define IPV6_RTHDR 51 /* ip6_rthdr; send routing header */
#define IPV6_AUTH_LEVEL 53 /* int; authentication used */
-/* $OpenBSD: in6_src.c,v 1.84 2020/11/07 09:51:40 denis Exp $ */
+/* $OpenBSD: in6_src.c,v 1.85 2021/03/10 10:21:49 jsg Exp $ */
/* $KAME: in6_src.c,v 1.36 2001/02/06 04:08:17 itojun Exp $ */
/*
/*
* Return an IPv6 address, which is the most appropriate for a given
* destination and pcb. We need the additional opt parameter because
- * the values set at pcb level can be overriden via cmsg.
+ * the values set at pcb level can be overridden via cmsg.
*/
int
in6_pcbselsrc(struct in6_addr **in6src, struct sockaddr_in6 *dstsock,
/*
* Use preferred source address if :
* - destination is not onlink
- * - preferred source addresss is set
+ * - preferred source address is set
* - output interface is UP
*/
if (ro->ro_rt && !(ro->ro_rt->rt_flags & RTF_LLINFO) &&
}
/*
- * just clear the embedded scope identifer.
+ * just clear the embedded scope identifier.
*/
void
in6_clearscope(struct in6_addr *addr)
-/* $OpenBSD: ip6_id.c,v 1.15 2021/03/01 11:05:43 bluhm Exp $ */
+/* $OpenBSD: ip6_id.c,v 1.16 2021/03/10 10:21:49 jsg Exp $ */
/* $NetBSD: ip6_id.c,v 1.7 2003/09/13 21:32:59 itojun Exp $ */
/* $KAME: ip6_id.c,v 1.8 2003/09/06 13:41:06 itojun Exp $ */
struct randomtab {
const int ru_bits; /* resulting bits */
- const long ru_out; /* Time after wich will be reseeded */
+ const long ru_out; /* Time after which will be reseeded */
const u_int32_t ru_max; /* Uniq cycle, avoid blackjack prediction */
const u_int32_t ru_gen; /* Starting generator */
const u_int32_t ru_n; /* ru_n: prime, ru_n - 1: product of pfacts[] */
static struct randomtab randomtab_20 = {
20, /* resulting bits */
- 180, /* Time after wich will be reseeded */
+ 180, /* Time after which will be reseeded */
200000, /* Uniq cycle, avoid blackjack prediction */
2, /* Starting generator */
524269, /* RU_N-1 = 2^2*3^2*14563 */
-/* $OpenBSD: ip6_input.c,v 1.231 2021/02/25 02:48:21 dlg Exp $ */
+/* $OpenBSD: ip6_input.c,v 1.232 2021/03/10 10:21:49 jsg Exp $ */
/* $KAME: ip6_input.c,v 1.188 2001/03/29 05:34:31 itojun Exp $ */
/*
if (ip6_hbhchcheck(*mp, offp, &nxt, NULL))
return IPPROTO_DONE;
- /* Check wheter we are already in a IPv4/IPv6 local deliver loop. */
+ /* Check whether we are already in a IPv4/IPv6 local deliver loop. */
if (af == AF_UNSPEC)
nxt = ip_deliver(mp, offp, nxt, AF_INET6);
return nxt;
-/* $OpenBSD: ip6_mroute.c,v 1.125 2020/06/24 22:03:44 cheloha Exp $ */
+/* $OpenBSD: ip6_mroute.c,v 1.126 2021/03/10 10:21:49 jsg Exp $ */
/* $NetBSD: ip6_mroute.c,v 1.59 2003/12/10 09:28:38 itojun Exp $ */
/* $KAME: ip6_mroute.c,v 1.45 2001/03/25 08:38:51 itojun Exp $ */
mb_copy->m_flags |= M_MCAST;
/*
- * If we sourced the packet, call ip6_output since we may devide
+ * If we sourced the packet, call ip6_output since we may divide
* the packet into fragments when the packet is too big for the
* outgoing interface.
* Otherwise, we can simply send the packet to the interface
-/* $OpenBSD: ip6_output.c,v 1.255 2021/03/01 11:05:43 bluhm Exp $ */
+/* $OpenBSD: ip6_output.c,v 1.256 2021/03/10 10:21:49 jsg Exp $ */
/* $KAME: ip6_output.c,v 1.172 2001/03/25 09:55:56 itojun Exp $ */
/*
}
/*
- * If this packet is going trough a loopback interface we wont
+ * If this packet is going through a loopback interface we won't
* be able to restore its scope ID using the interface index.
*/
if (IN6_IS_SCOPE_EMBED(&ip6->ip6_src)) {
-/* $OpenBSD: ip6protosw.h,v 1.13 2017/11/23 13:45:46 mpi Exp $ */
+/* $OpenBSD: ip6protosw.h,v 1.14 2021/03/10 10:21:49 jsg Exp $ */
/* $KAME: ip6protosw.h,v 1.22 2001/02/08 18:02:08 itojun Exp $ */
/*
*
* ip6c_finaldst usually points to ip6c_ip6->ip6_dst. if the original
* (internal) packet carries a routing header, it may point the final
- * dstination address in the routing header.
+ * destination address in the routing header.
*
* ip6c_src: ip6c_ip6->ip6_src + scope info + flowlabel in ip6c_ip6
* (beware of flowlabel, if you try to compare it against others)
-/* $OpenBSD: udp6_output.c,v 1.56 2018/09/13 19:53:58 bluhm Exp $ */
+/* $OpenBSD: udp6_output.c,v 1.57 2021/03/10 10:21:49 jsg Exp $ */
/* $KAME: udp6_output.c,v 1.21 2001/02/07 11:51:54 itojun Exp $ */
/*
#include <netinet6/ip6protosw.h>
/*
- * UDP protocol inplementation.
+ * UDP protocol implementation.
* Per RFC 768, August, 1980.
*/
int
-/* $OpenBSD: mpls.h,v 1.44 2020/08/19 19:22:53 gnezdo Exp $ */
+/* $OpenBSD: mpls.h,v 1.45 2021/03/10 10:21:49 jsg Exp $ */
/*
* Copyright (C) 1999, 2000 and 2001 AYAME Project, WIDE Project.
#define MPLS_BOS_ISSET(l) (((l) & MPLS_BOS_MASK) == MPLS_BOS_MASK)
-/* Reserved lavel values (RFC3032) */
+/* Reserved label values (RFC3032) */
#define MPLS_LABEL_IPV4NULL 0 /* IPv4 Explicit NULL Label */
#define MPLS_LABEL_RTALERT 1 /* Router Alert Label */
#define MPLS_LABEL_IPV6NULL 2 /* IPv6 Explicit NULL Label */
-/* $OpenBSD: mpls_input.c,v 1.76 2020/01/24 05:14:52 jsg Exp $ */
+/* $OpenBSD: mpls_input.c,v 1.77 2021/03/10 10:21:49 jsg Exp $ */
/*
* Copyright (c) 2008 Claudio Jeker <claudio@openbsd.org>
return (NULL);
ip = mtod(m, struct ip *);
- /* stuff to fix up which is normaly done in ip_output */
+ /* stuff to fix up which is normally done in ip_output */
ip->ip_v = IPVERSION;
ip->ip_id = htons(ip_randomid());
ip->ip_sum = 0;
-/* $OpenBSD: domain.h,v 1.20 2019/06/13 08:12:11 claudio Exp $ */
+/* $OpenBSD: domain.h,v 1.21 2021/03/10 10:21:47 jsg Exp $ */
/* $NetBSD: domain.h,v 1.10 1996/02/09 18:25:07 christos Exp $ */
/*
/* initialize routing table */
unsigned int dom_sasize; /* size of sockaddr structure */
unsigned int dom_rtoffset; /* offset of the key, in bytes */
- unsigned int dom_maxplen; /* maxium prefix length, in bits */
+ unsigned int dom_maxplen; /* maximum prefix length, in bits */
void *(*dom_ifattach)(struct ifnet *);
void (*dom_ifdetach)(struct ifnet *, void *);
/* af-dependent data on ifnet */
-/* $OpenBSD: exec_elf.h,v 1.88 2020/07/06 13:33:09 pirofti Exp $ */
+/* $OpenBSD: exec_elf.h,v 1.89 2021/03/10 10:21:47 jsg Exp $ */
/*
* Copyright (c) 1995, 1996 Erik Theisen. All rights reserved.
*
* NT_OPENBSD_PROCINFO
* Note is a "elfcore_procinfo" structure.
* NT_OPENBSD_AUXV
- * Note is a a bunch of Auxilliary Vectors, terminated by
+ * Note is a a bunch of Auxiliary Vectors, terminated by
* an AT_NULL entry.
* NT_OPENBSD_REGS
* Note is a "reg" structure.
-/* $OpenBSD: ktrace.h,v 1.39 2020/09/14 07:15:25 mpi Exp $ */
+/* $OpenBSD: ktrace.h,v 1.40 2021/03/10 10:21:47 jsg Exp $ */
/* $NetBSD: ktrace.h,v 1.12 1996/02/04 02:12:29 christos Exp $ */
/*
};
/*
- * KTR_EXECARGS and KTR_EXECENV - args and evironment records
+ * KTR_EXECARGS and KTR_EXECENV - args and environment records
*/
#define KTR_EXECARGS 10
#define KTR_EXECENV 11
-/* $OpenBSD: param.h,v 1.132 2021/02/06 21:26:19 deraadt Exp $ */
+/* $OpenBSD: param.h,v 1.133 2021/03/10 10:21:47 jsg Exp $ */
/*-
* Copyright (c) 1982, 1986, 1989, 1993
#define PRIMASK 0x0ff
#define PCATCH 0x100 /* OR'd with pri for tsleep to check signals */
-#define PNORELOCK 0x200 /* OR'd with pri for msleep to not reaquire
+#define PNORELOCK 0x200 /* OR'd with pri for msleep to not reacquire
the mutex */
#endif /* _KERNEL */
-/* $OpenBSD: shm.h,v 1.29 2019/11/03 20:16:01 guenther Exp $ */
+/* $OpenBSD: shm.h,v 1.30 2021/03/10 10:21:47 jsg Exp $ */
/* $NetBSD: shm.h,v 1.20 1996/04/09 20:55:35 cgd Exp $ */
/*
#define SHM_UNLOCK 4 /* Unlock a segment locked by SHM_LOCK. */
/*
- * Segment low boundry address multiple
+ * Segment low boundary address multiple
*/
#define SHMLBA (1U << _MAX_PAGE_SHIFT)
-/* $OpenBSD: sysctl.h,v 1.213 2020/12/28 18:28:11 mglocker Exp $ */
+/* $OpenBSD: sysctl.h,v 1.214 2021/03/10 10:21:47 jsg Exp $ */
/* $NetBSD: sysctl.h,v 1.16 1996/04/09 20:55:36 cgd Exp $ */
/*
/* was KERN_RND 31 */
#define KERN_NOSUIDCOREDUMP 32 /* int: no setuid coredumps ever */
#define KERN_FSYNC 33 /* int: file synchronization support */
-#define KERN_SYSVMSG 34 /* int: SysV message queue suppoprt */
+#define KERN_SYSVMSG 34 /* int: SysV message queue support */
#define KERN_SYSVSEM 35 /* int: SysV semaphore support */
#define KERN_SYSVSHM 36 /* int: SysV shared memory support */
/* was KERN_ARND 37 */
-/* $OpenBSD: wait.h,v 1.17 2014/06/13 22:40:31 matthew Exp $ */
+/* $OpenBSD: wait.h,v 1.18 2021/03/10 10:21:47 jsg Exp $ */
/* $NetBSD: wait.h,v 1.11 1996/04/09 20:55:51 cgd Exp $ */
/*
#include <sys/cdefs.h>
/*
- * This file holds definitions relevent to the wait4 system call
+ * This file holds definitions relevant to the wait4 system call
* and the alternate interfaces that use it (wait, wait3, waitpid).
*/