ethernet.rs 26 KB

123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312313314315316317318319320321322323324325326327328329330331332333334335336337338339340341342343344345346347348349350351352353354355356357358359360361362363364365366367368369370371372373374375376377378379380381382383384385386387388389390391392393394395396397398399400401402403404405406407408409410411412413414415416417418419420421422423424425426427428429430431432433434435436437438439440441442443444445446447448449450451452453454455456457458459460461462463464465466467468469470471472473474475476477478479480481482483484485486487488489490491492493494495496497498499500501502503504505506507508509510511512513514515516517518519520521522523524525526527528529530531532533534535536537538539540541542543544545546547548549550551552553554555556557558559560561562563564565566567568569570571572573574575576577578579580581582583584585586587588589590591592593594595596597598599600601602603604605606607608609610611612613614615616617618619620621622623624625626627628629630631632633634635636637638639640641642643644645646647648649650651652653
  1. // Heads up! Before working on this file you should read the parts
  2. // of RFC 1122 that discuss Ethernet, ARP and IP.
  3. use managed::{Managed, ManagedSlice};
  4. use {Error, Result};
  5. use phy::Device;
  6. use wire::{EthernetAddress, EthernetProtocol, EthernetFrame};
  7. use wire::{Ipv4Address};
  8. use wire::{IpAddress, IpProtocol, IpRepr, IpCidr};
  9. use wire::{ArpPacket, ArpRepr, ArpOperation};
  10. use wire::{Ipv4Packet, Ipv4Repr};
  11. use wire::{Icmpv4Packet, Icmpv4Repr, Icmpv4DstUnreachable};
  12. #[cfg(feature = "socket-udp")] use wire::{UdpPacket, UdpRepr};
  13. #[cfg(feature = "socket-tcp")] use wire::{TcpPacket, TcpRepr, TcpControl};
  14. use socket::{Socket, SocketSet, AnySocket};
  15. #[cfg(feature = "socket-raw")] use socket::RawSocket;
  16. #[cfg(feature = "socket-udp")] use socket::UdpSocket;
  17. #[cfg(feature = "socket-tcp")] use socket::TcpSocket;
  18. use super::ArpCache;
  19. /// An Ethernet network interface.
  20. ///
  21. /// The network interface logically owns a number of other data structures; to avoid
  22. /// a dependency on heap allocation, it instead owns a `BorrowMut<[T]>`, which can be
  23. /// a `&mut [T]`, or `Vec<T>` if a heap is available.
  24. pub struct Interface<'a, 'b, 'c, DeviceT: Device + 'a> {
  25. device: Managed<'a, DeviceT>,
  26. arp_cache: Managed<'b, ArpCache>,
  27. ethernet_addr: EthernetAddress,
  28. ip_addrs: ManagedSlice<'c, IpCidr>,
  29. ipv4_gateway: Option<Ipv4Address>,
  30. }
  31. enum Packet<'a> {
  32. None,
  33. Arp(ArpRepr),
  34. Icmpv4(Ipv4Repr, Icmpv4Repr<'a>),
  35. #[cfg(feature = "socket-raw")]
  36. Raw((IpRepr, &'a [u8])),
  37. #[cfg(feature = "socket-udp")]
  38. Udp((IpRepr, UdpRepr<'a>)),
  39. #[cfg(feature = "socket-tcp")]
  40. Tcp((IpRepr, TcpRepr<'a>))
  41. }
  42. impl<'a, 'b, 'c, DeviceT: Device + 'a> Interface<'a, 'b, 'c, DeviceT> {
  43. /// Create a network interface using the provided network device.
  44. ///
  45. /// # Panics
  46. /// See the restrictions on [set_hardware_addr](#method.set_hardware_addr)
  47. /// and [set_protocol_addrs](#method.set_protocol_addrs) functions.
  48. pub fn new<DeviceMT, ArpCacheMT, ProtocolAddrsMT, Ipv4GatewayAddrT>
  49. (device: DeviceMT, arp_cache: ArpCacheMT,
  50. ethernet_addr: EthernetAddress,
  51. ip_addrs: ProtocolAddrsMT,
  52. ipv4_gateway: Ipv4GatewayAddrT) ->
  53. Interface<'a, 'b, 'c, DeviceT>
  54. where DeviceMT: Into<Managed<'a, DeviceT>>,
  55. ArpCacheMT: Into<Managed<'b, ArpCache>>,
  56. ProtocolAddrsMT: Into<ManagedSlice<'c, IpCidr>>,
  57. Ipv4GatewayAddrT: Into<Option<Ipv4Address>>, {
  58. let device = device.into();
  59. let arp_cache = arp_cache.into();
  60. let ip_addrs = ip_addrs.into();
  61. let ipv4_gateway = ipv4_gateway.into();
  62. Self::check_ethernet_addr(&ethernet_addr);
  63. Self::check_ip_addrs(&ip_addrs);
  64. Interface { device, arp_cache, ethernet_addr, ip_addrs, ipv4_gateway }
  65. }
  66. fn check_ethernet_addr(addr: &EthernetAddress) {
  67. if addr.is_multicast() {
  68. panic!("Ethernet address {} is not unicast", addr)
  69. }
  70. }
  71. /// Get the Ethernet address of the interface.
  72. pub fn ethernet_addr(&self) -> EthernetAddress {
  73. self.ethernet_addr
  74. }
  75. /// Set the Ethernet address of the interface.
  76. ///
  77. /// # Panics
  78. /// This function panics if the address is not unicast.
  79. pub fn set_ethernet_addr(&mut self, addr: EthernetAddress) {
  80. self.ethernet_addr = addr;
  81. Self::check_ethernet_addr(&self.ethernet_addr);
  82. }
  83. fn check_ip_addrs(addrs: &[IpCidr]) {
  84. for cidr in addrs {
  85. if !cidr.address().is_unicast() {
  86. panic!("IP address {} is not unicast", cidr.address())
  87. }
  88. }
  89. }
  90. /// Get the IP addresses of the interface.
  91. pub fn ip_addrs(&self) -> &[IpCidr] {
  92. self.ip_addrs.as_ref()
  93. }
  94. /// Update the IP addresses of the interface.
  95. ///
  96. /// # Panics
  97. /// This function panics if any of the addresses is not unicast.
  98. pub fn update_ip_addrs<F: FnOnce(&mut ManagedSlice<'c, IpCidr>)>(&mut self, f: F) {
  99. f(&mut self.ip_addrs);
  100. Self::check_ip_addrs(&self.ip_addrs)
  101. }
  102. /// Check whether the interface has the given IP address assigned.
  103. pub fn has_ip_addr<T: Into<IpAddress>>(&self, addr: T) -> bool {
  104. let addr = addr.into();
  105. self.ip_addrs.iter().any(|probe| probe.address() == addr)
  106. }
  107. /// Get the IPv4 gateway of the interface.
  108. pub fn ipv4_gateway(&self) -> Option<Ipv4Address> {
  109. self.ipv4_gateway
  110. }
  111. /// Set the IPv4 gateway of the interface.
  112. pub fn set_ipv4_gateway<GatewayAddrT>(&mut self, gateway: GatewayAddrT)
  113. where GatewayAddrT: Into<Option<Ipv4Address>> {
  114. self.ipv4_gateway = gateway.into();
  115. }
  116. /// Transmit packets queued in the given sockets, and receive packets queued
  117. /// in the device.
  118. ///
  119. /// The timestamp must be a number of milliseconds, monotonically increasing
  120. /// since an arbitrary moment in time, such as system startup.
  121. ///
  122. /// This function returns a _soft deadline_ for calling it the next time.
  123. /// That is, if `iface.poll(&mut sockets, 1000)` returns `Ok(Some(2000))`,
  124. /// it harmless (but wastes energy) to call it 500 ms later, and potentially
  125. /// harmful (impacting quality of service) to call it 1500 ms later.
  126. ///
  127. /// # Errors
  128. /// This method will routinely return errors in response to normal network
  129. /// activity as well as certain boundary conditions such as buffer exhaustion.
  130. /// These errors are provided as an aid for troubleshooting, and are meant
  131. /// to be logged and ignored.
  132. ///
  133. /// As a special case, `Err(Error::Unrecognized)` is returned in response to
  134. /// packets containing any unsupported protocol, option, or form, which is
  135. /// a very common occurrence and on a production system it should not even
  136. /// be logged.
  137. pub fn poll(&mut self, sockets: &mut SocketSet, timestamp: u64) -> Result<Option<u64>> {
  138. self.socket_egress(sockets, timestamp)?;
  139. if self.socket_ingress(sockets, timestamp)? {
  140. Ok(Some(0))
  141. } else {
  142. Ok(sockets.iter().filter_map(|socket| socket.poll_at()).min())
  143. }
  144. }
  145. fn socket_ingress(&mut self, sockets: &mut SocketSet, timestamp: u64) -> Result<bool> {
  146. let mut processed_any = false;
  147. loop {
  148. let frame =
  149. match self.device.receive(timestamp) {
  150. Ok(frame) => frame,
  151. Err(Error::Exhausted) => break, // nothing to receive
  152. Err(err) => return Err(err)
  153. };
  154. let response =
  155. match self.process_ethernet(sockets, timestamp, &frame) {
  156. Ok(response) => response,
  157. Err(err) => {
  158. net_debug!("cannot process ingress packet: {}", err);
  159. if net_log_enabled!(debug) {
  160. match EthernetFrame::new_checked(frame.as_ref()) {
  161. Err(_) => {
  162. net_debug!("packet dump follows:\n{:?}", frame.as_ref());
  163. }
  164. Ok(frame) => {
  165. net_debug!("packet dump follows:\n{}", frame);
  166. }
  167. }
  168. }
  169. return Err(err)
  170. }
  171. };
  172. processed_any = true;
  173. match self.dispatch(timestamp, response) {
  174. Ok(()) => (),
  175. Err(err) => {
  176. net_debug!("cannot dispatch response packet: {}", err);
  177. return Err(err)
  178. }
  179. }
  180. }
  181. Ok(processed_any)
  182. }
  183. fn socket_egress(&mut self, sockets: &mut SocketSet, timestamp: u64) -> Result<()> {
  184. let mut caps = self.device.capabilities();
  185. caps.max_transmission_unit -= EthernetFrame::<&[u8]>::header_len();
  186. for mut socket in sockets.iter_mut() {
  187. let mut device_result = Ok(());
  188. let socket_result =
  189. match *socket {
  190. #[cfg(feature = "socket-raw")]
  191. Socket::Raw(ref mut socket) =>
  192. socket.dispatch(|response| {
  193. device_result = self.dispatch(timestamp, Packet::Raw(response));
  194. device_result
  195. }, &caps.checksum),
  196. #[cfg(feature = "socket-udp")]
  197. Socket::Udp(ref mut socket) =>
  198. socket.dispatch(|response| {
  199. device_result = self.dispatch(timestamp, Packet::Udp(response));
  200. device_result
  201. }),
  202. #[cfg(feature = "socket-tcp")]
  203. Socket::Tcp(ref mut socket) =>
  204. socket.dispatch(timestamp, &caps, |response| {
  205. device_result = self.dispatch(timestamp, Packet::Tcp(response));
  206. device_result
  207. }),
  208. Socket::__Nonexhaustive(_) => unreachable!()
  209. };
  210. match (device_result, socket_result) {
  211. (Err(Error::Unaddressable), _) => break, // no one to transmit to
  212. (Err(Error::Exhausted), _) => break, // nowhere to transmit
  213. (Ok(()), Err(Error::Exhausted)) => (), // nothing to transmit
  214. (Err(err), _) | (_, Err(err)) => {
  215. net_debug!("cannot dispatch egress packet: {}", err);
  216. return Err(err)
  217. }
  218. (Ok(()), Ok(())) => ()
  219. }
  220. }
  221. Ok(())
  222. }
  223. fn process_ethernet<'frame, T: AsRef<[u8]>>
  224. (&mut self, sockets: &mut SocketSet, timestamp: u64,
  225. frame: &'frame T) ->
  226. Result<Packet<'frame>> {
  227. let eth_frame = EthernetFrame::new_checked(frame)?;
  228. // Ignore any packets not directed to our hardware address.
  229. if !eth_frame.dst_addr().is_broadcast() &&
  230. eth_frame.dst_addr() != self.ethernet_addr {
  231. return Ok(Packet::None)
  232. }
  233. match eth_frame.ethertype() {
  234. EthernetProtocol::Arp =>
  235. self.process_arp(&eth_frame),
  236. EthernetProtocol::Ipv4 =>
  237. self.process_ipv4(sockets, timestamp, &eth_frame),
  238. // Drop all other traffic.
  239. _ => Err(Error::Unrecognized),
  240. }
  241. }
  242. fn process_arp<'frame, T: AsRef<[u8]>>
  243. (&mut self, eth_frame: &EthernetFrame<&'frame T>) ->
  244. Result<Packet<'frame>> {
  245. let arp_packet = ArpPacket::new_checked(eth_frame.payload())?;
  246. let arp_repr = ArpRepr::parse(&arp_packet)?;
  247. match arp_repr {
  248. // Respond to ARP requests aimed at us, and fill the ARP cache from all ARP
  249. // requests and replies, to minimize the chance that we have to perform
  250. // an explicit ARP request.
  251. ArpRepr::EthernetIpv4 {
  252. operation, source_hardware_addr, source_protocol_addr, target_protocol_addr, ..
  253. } => {
  254. if source_protocol_addr.is_unicast() && source_hardware_addr.is_unicast() {
  255. self.arp_cache.fill(&source_protocol_addr.into(),
  256. &source_hardware_addr);
  257. } else {
  258. // Discard packets with non-unicast source addresses.
  259. net_debug!("non-unicast source address");
  260. return Err(Error::Malformed)
  261. }
  262. if operation == ArpOperation::Request && self.has_ip_addr(target_protocol_addr) {
  263. Ok(Packet::Arp(ArpRepr::EthernetIpv4 {
  264. operation: ArpOperation::Reply,
  265. source_hardware_addr: self.ethernet_addr,
  266. source_protocol_addr: target_protocol_addr,
  267. target_hardware_addr: source_hardware_addr,
  268. target_protocol_addr: source_protocol_addr
  269. }))
  270. } else {
  271. Ok(Packet::None)
  272. }
  273. }
  274. _ => Err(Error::Unrecognized)
  275. }
  276. }
  277. fn process_ipv4<'frame, T: AsRef<[u8]>>
  278. (&mut self, sockets: &mut SocketSet, _timestamp: u64,
  279. eth_frame: &EthernetFrame<&'frame T>) ->
  280. Result<Packet<'frame>> {
  281. let ipv4_packet = Ipv4Packet::new_checked(eth_frame.payload())?;
  282. let checksum_caps = self.device.capabilities().checksum;
  283. let ipv4_repr = Ipv4Repr::parse(&ipv4_packet, &checksum_caps)?;
  284. if !ipv4_repr.src_addr.is_unicast() {
  285. // Discard packets with non-unicast source addresses.
  286. net_debug!("non-unicast source address");
  287. return Err(Error::Malformed)
  288. }
  289. if eth_frame.src_addr().is_unicast() {
  290. // Fill the ARP cache from IP header of unicast frames.
  291. self.arp_cache.fill(&IpAddress::Ipv4(ipv4_repr.src_addr),
  292. &eth_frame.src_addr());
  293. }
  294. let ip_repr = IpRepr::Ipv4(ipv4_repr);
  295. let ip_payload = ipv4_packet.payload();
  296. #[cfg(feature = "socket-raw")]
  297. let mut handled_by_raw_socket = false;
  298. // Pass every IP packet to all raw sockets we have registered.
  299. #[cfg(feature = "socket-raw")]
  300. for mut raw_socket in sockets.iter_mut().filter_map(RawSocket::downcast) {
  301. if !raw_socket.accepts(&ip_repr) { continue }
  302. match raw_socket.process(&ip_repr, ip_payload, &checksum_caps) {
  303. // The packet is valid and handled by socket.
  304. Ok(()) => handled_by_raw_socket = true,
  305. // The socket buffer is full.
  306. Err(Error::Exhausted) => (),
  307. // Raw sockets don't validate the packets in any way.
  308. Err(_) => unreachable!(),
  309. }
  310. }
  311. if !self.has_ip_addr(ipv4_repr.dst_addr) {
  312. // Ignore IP packets not directed at us.
  313. return Ok(Packet::None)
  314. }
  315. match ipv4_repr.protocol {
  316. IpProtocol::Icmp =>
  317. self.process_icmpv4(ipv4_repr, ip_payload),
  318. #[cfg(feature = "socket-udp")]
  319. IpProtocol::Udp =>
  320. self.process_udp(sockets, ip_repr, ip_payload),
  321. #[cfg(feature = "socket-tcp")]
  322. IpProtocol::Tcp =>
  323. self.process_tcp(sockets, _timestamp, ip_repr, ip_payload),
  324. #[cfg(feature = "socket-raw")]
  325. _ if handled_by_raw_socket =>
  326. Ok(Packet::None),
  327. _ => {
  328. let icmp_reply_repr = Icmpv4Repr::DstUnreachable {
  329. reason: Icmpv4DstUnreachable::ProtoUnreachable,
  330. header: ipv4_repr,
  331. data: &ip_payload[0..8]
  332. };
  333. let ipv4_reply_repr = Ipv4Repr {
  334. src_addr: ipv4_repr.dst_addr,
  335. dst_addr: ipv4_repr.src_addr,
  336. protocol: IpProtocol::Icmp,
  337. payload_len: icmp_reply_repr.buffer_len(),
  338. ttl: 64,
  339. };
  340. Ok(Packet::Icmpv4(ipv4_reply_repr, icmp_reply_repr))
  341. }
  342. }
  343. }
  344. fn process_icmpv4<'frame>(&self, ipv4_repr: Ipv4Repr, ip_payload: &'frame [u8]) ->
  345. Result<Packet<'frame>> {
  346. let icmp_packet = Icmpv4Packet::new_checked(ip_payload)?;
  347. let checksum_caps = self.device.capabilities().checksum;
  348. let icmp_repr = Icmpv4Repr::parse(&icmp_packet, &checksum_caps)?;
  349. match icmp_repr {
  350. // Respond to echo requests.
  351. Icmpv4Repr::EchoRequest { ident, seq_no, data } => {
  352. let icmp_reply_repr = Icmpv4Repr::EchoReply {
  353. ident: ident,
  354. seq_no: seq_no,
  355. data: data
  356. };
  357. let ipv4_reply_repr = Ipv4Repr {
  358. src_addr: ipv4_repr.dst_addr,
  359. dst_addr: ipv4_repr.src_addr,
  360. protocol: IpProtocol::Icmp,
  361. payload_len: icmp_reply_repr.buffer_len(),
  362. ttl: 64
  363. };
  364. Ok(Packet::Icmpv4(ipv4_reply_repr, icmp_reply_repr))
  365. }
  366. // Ignore any echo replies.
  367. Icmpv4Repr::EchoReply { .. } => Ok(Packet::None),
  368. // FIXME: do something correct here?
  369. _ => Err(Error::Unrecognized),
  370. }
  371. }
  372. #[cfg(feature = "socket-udp")]
  373. fn process_udp<'frame>(&self, sockets: &mut SocketSet,
  374. ip_repr: IpRepr, ip_payload: &'frame [u8]) ->
  375. Result<Packet<'frame>> {
  376. let (src_addr, dst_addr) = (ip_repr.src_addr(), ip_repr.dst_addr());
  377. let udp_packet = UdpPacket::new_checked(ip_payload)?;
  378. let checksum_caps = self.device.capabilities().checksum;
  379. let udp_repr = UdpRepr::parse(&udp_packet, &src_addr, &dst_addr, &checksum_caps)?;
  380. for mut udp_socket in sockets.iter_mut().filter_map(UdpSocket::downcast) {
  381. if !udp_socket.accepts(&ip_repr, &udp_repr) { continue }
  382. match udp_socket.process(&ip_repr, &udp_repr) {
  383. // The packet is valid and handled by socket.
  384. Ok(()) => return Ok(Packet::None),
  385. // The packet is malformed, or the socket buffer is full.
  386. Err(e) => return Err(e)
  387. }
  388. }
  389. // The packet wasn't handled by a socket, send an ICMP port unreachable packet.
  390. match ip_repr {
  391. IpRepr::Ipv4(ipv4_repr) => {
  392. let icmpv4_reply_repr = Icmpv4Repr::DstUnreachable {
  393. reason: Icmpv4DstUnreachable::PortUnreachable,
  394. header: ipv4_repr,
  395. data: &ip_payload[0..8]
  396. };
  397. let ipv4_reply_repr = Ipv4Repr {
  398. src_addr: ipv4_repr.dst_addr,
  399. dst_addr: ipv4_repr.src_addr,
  400. protocol: IpProtocol::Icmp,
  401. payload_len: icmpv4_reply_repr.buffer_len(),
  402. ttl: 64,
  403. };
  404. Ok(Packet::Icmpv4(ipv4_reply_repr, icmpv4_reply_repr))
  405. },
  406. IpRepr::Unspecified { .. } |
  407. IpRepr::__Nonexhaustive =>
  408. unreachable!()
  409. }
  410. }
  411. #[cfg(feature = "socket-tcp")]
  412. fn process_tcp<'frame>(&self, sockets: &mut SocketSet, timestamp: u64,
  413. ip_repr: IpRepr, ip_payload: &'frame [u8]) ->
  414. Result<Packet<'frame>> {
  415. let (src_addr, dst_addr) = (ip_repr.src_addr(), ip_repr.dst_addr());
  416. let tcp_packet = TcpPacket::new_checked(ip_payload)?;
  417. let checksum_caps = self.device.capabilities().checksum;
  418. let tcp_repr = TcpRepr::parse(&tcp_packet, &src_addr, &dst_addr, &checksum_caps)?;
  419. for mut tcp_socket in sockets.iter_mut().filter_map(TcpSocket::downcast) {
  420. if !tcp_socket.accepts(&ip_repr, &tcp_repr) { continue }
  421. match tcp_socket.process(timestamp, &ip_repr, &tcp_repr) {
  422. // The packet is valid and handled by socket.
  423. Ok(reply) => return Ok(reply.map_or(Packet::None, Packet::Tcp)),
  424. // The packet is malformed, or doesn't match the socket state,
  425. // or the socket buffer is full.
  426. Err(e) => return Err(e)
  427. }
  428. }
  429. if tcp_repr.control == TcpControl::Rst {
  430. // Never reply to a TCP RST packet with another TCP RST packet.
  431. Ok(Packet::None)
  432. } else {
  433. // The packet wasn't handled by a socket, send a TCP RST packet.
  434. Ok(Packet::Tcp(TcpSocket::rst_reply(&ip_repr, &tcp_repr)))
  435. }
  436. }
  437. fn dispatch(&mut self, timestamp: u64, packet: Packet) -> Result<()> {
  438. let checksum_caps = self.device.capabilities().checksum;
  439. match packet {
  440. Packet::Arp(arp_repr) => {
  441. let dst_hardware_addr =
  442. match arp_repr {
  443. ArpRepr::EthernetIpv4 { target_hardware_addr, .. } => target_hardware_addr,
  444. _ => unreachable!()
  445. };
  446. self.dispatch_ethernet(timestamp, arp_repr.buffer_len(), |mut frame| {
  447. frame.set_dst_addr(dst_hardware_addr);
  448. frame.set_ethertype(EthernetProtocol::Arp);
  449. let mut packet = ArpPacket::new(frame.payload_mut());
  450. arp_repr.emit(&mut packet);
  451. })
  452. },
  453. Packet::Icmpv4(ipv4_repr, icmpv4_repr) => {
  454. self.dispatch_ip(timestamp, IpRepr::Ipv4(ipv4_repr), |_ip_repr, payload| {
  455. icmpv4_repr.emit(&mut Icmpv4Packet::new(payload), &checksum_caps);
  456. })
  457. }
  458. #[cfg(feature = "socket-raw")]
  459. Packet::Raw((ip_repr, raw_packet)) => {
  460. self.dispatch_ip(timestamp, ip_repr, |_ip_repr, payload| {
  461. payload.copy_from_slice(raw_packet);
  462. })
  463. }
  464. #[cfg(feature = "socket-udp")]
  465. Packet::Udp((ip_repr, udp_repr)) => {
  466. self.dispatch_ip(timestamp, ip_repr, |ip_repr, payload| {
  467. udp_repr.emit(&mut UdpPacket::new(payload),
  468. &ip_repr.src_addr(), &ip_repr.dst_addr(),
  469. &checksum_caps);
  470. })
  471. }
  472. #[cfg(feature = "socket-tcp")]
  473. Packet::Tcp((ip_repr, mut tcp_repr)) => {
  474. let caps = self.device.capabilities();
  475. self.dispatch_ip(timestamp, ip_repr, |ip_repr, payload| {
  476. // This is a terrible hack to make TCP performance more acceptable on systems
  477. // where the TCP buffers are significantly larger than network buffers,
  478. // e.g. a 64 kB TCP receive buffer (and so, when empty, a 64k window)
  479. // together with four 1500 B Ethernet receive buffers. If left untreated,
  480. // this would result in our peer pushing our window and sever packet loss.
  481. //
  482. // I'm really not happy about this "solution" but I don't know what else to do.
  483. if let Some(max_burst_size) = caps.max_burst_size {
  484. let mut max_segment_size = caps.max_transmission_unit;
  485. max_segment_size -= EthernetFrame::<&[u8]>::header_len();
  486. max_segment_size -= ip_repr.buffer_len();
  487. max_segment_size -= tcp_repr.header_len();
  488. let max_window_size = max_burst_size * max_segment_size;
  489. if tcp_repr.window_len as usize > max_window_size {
  490. tcp_repr.window_len = max_window_size as u16;
  491. }
  492. }
  493. tcp_repr.emit(&mut TcpPacket::new(payload),
  494. &ip_repr.src_addr(), &ip_repr.dst_addr(),
  495. &checksum_caps);
  496. })
  497. }
  498. Packet::None => Ok(())
  499. }
  500. }
  501. fn dispatch_ethernet<F>(&mut self, timestamp: u64, buffer_len: usize, f: F) -> Result<()>
  502. where F: FnOnce(EthernetFrame<&mut [u8]>) {
  503. let tx_len = EthernetFrame::<&[u8]>::buffer_len(buffer_len);
  504. let mut tx_buffer = self.device.transmit(timestamp, tx_len)?;
  505. debug_assert!(tx_buffer.as_ref().len() == tx_len);
  506. let mut frame = EthernetFrame::new(tx_buffer.as_mut());
  507. frame.set_src_addr(self.ethernet_addr);
  508. f(frame);
  509. Ok(())
  510. }
  511. fn route(&self, addr: &IpAddress) -> Result<IpAddress> {
  512. self.ip_addrs
  513. .iter()
  514. .find(|cidr| cidr.contains_addr(&addr))
  515. .map(|_cidr| Ok(addr.clone())) // route directly
  516. .unwrap_or_else(|| {
  517. match (addr, self.ipv4_gateway) {
  518. // route via a gateway
  519. (&IpAddress::Ipv4(_), Some(gateway)) =>
  520. Ok(gateway.into()),
  521. // unroutable
  522. _ => Err(Error::Unaddressable)
  523. }
  524. })
  525. }
  526. fn lookup_hardware_addr(&mut self, timestamp: u64,
  527. src_addr: &IpAddress, dst_addr: &IpAddress) ->
  528. Result<EthernetAddress> {
  529. let dst_addr = self.route(dst_addr)?;
  530. if let Some(hardware_addr) = self.arp_cache.lookup(&dst_addr) {
  531. return Ok(hardware_addr)
  532. }
  533. if dst_addr.is_broadcast() {
  534. return Ok(EthernetAddress::BROADCAST)
  535. }
  536. match (src_addr, dst_addr) {
  537. (&IpAddress::Ipv4(src_addr), IpAddress::Ipv4(dst_addr)) => {
  538. net_debug!("address {} not in ARP cache, sending request",
  539. dst_addr);
  540. let arp_repr = ArpRepr::EthernetIpv4 {
  541. operation: ArpOperation::Request,
  542. source_hardware_addr: self.ethernet_addr,
  543. source_protocol_addr: src_addr,
  544. target_hardware_addr: EthernetAddress::BROADCAST,
  545. target_protocol_addr: dst_addr,
  546. };
  547. self.dispatch_ethernet(timestamp, arp_repr.buffer_len(), |mut frame| {
  548. frame.set_dst_addr(EthernetAddress::BROADCAST);
  549. frame.set_ethertype(EthernetProtocol::Arp);
  550. arp_repr.emit(&mut ArpPacket::new(frame.payload_mut()))
  551. })?;
  552. Err(Error::Unaddressable)
  553. }
  554. _ => unreachable!()
  555. }
  556. }
  557. fn dispatch_ip<F>(&mut self, timestamp: u64, ip_repr: IpRepr, f: F) -> Result<()>
  558. where F: FnOnce(IpRepr, &mut [u8]) {
  559. let ip_repr = ip_repr.lower(&self.ip_addrs)?;
  560. let checksum_caps = self.device.capabilities().checksum;
  561. let dst_hardware_addr =
  562. self.lookup_hardware_addr(timestamp, &ip_repr.src_addr(), &ip_repr.dst_addr())?;
  563. self.dispatch_ethernet(timestamp, ip_repr.total_len(), |mut frame| {
  564. frame.set_dst_addr(dst_hardware_addr);
  565. match ip_repr {
  566. IpRepr::Ipv4(_) => frame.set_ethertype(EthernetProtocol::Ipv4),
  567. _ => unreachable!()
  568. }
  569. ip_repr.emit(frame.payload_mut(), &checksum_caps);
  570. let payload = &mut frame.payload_mut()[ip_repr.buffer_len()..];
  571. f(ip_repr, payload)
  572. })
  573. }
  574. }