mirror of
https://github.com/edera-dev/krata.git
synced 2025-08-03 13:11:31 +00:00
network: implement support for smoltcp and ipstack
This commit is contained in:
@ -51,6 +51,7 @@ netlink-packet-route = "0.19.0"
|
|||||||
futures = "0.3.30"
|
futures = "0.3.30"
|
||||||
ipnetwork = "0.20.0"
|
ipnetwork = "0.20.0"
|
||||||
udp-stream = "0.0.11"
|
udp-stream = "0.0.11"
|
||||||
|
smoltcp = "0.11.0"
|
||||||
|
|
||||||
[workspace.dependencies.uuid]
|
[workspace.dependencies.uuid]
|
||||||
version = "1.6.1"
|
version = "1.6.1"
|
||||||
|
@ -284,15 +284,17 @@ impl ContainerInit {
|
|||||||
|
|
||||||
async fn network_setup(&mut self, network: &LaunchNetwork) -> Result<()> {
|
async fn network_setup(&mut self, network: &LaunchNetwork) -> Result<()> {
|
||||||
trace!(
|
trace!(
|
||||||
"setting up network with link {} and ipv4 {}",
|
"setting up network for link {} with ipv4 address {} and gateway {}",
|
||||||
network.link,
|
network.link,
|
||||||
network.ipv4
|
network.ipv4.address,
|
||||||
|
network.ipv4.gateway,
|
||||||
);
|
);
|
||||||
|
|
||||||
let (connection, handle, _) = rtnetlink::new_connection()?;
|
let (connection, handle, _) = rtnetlink::new_connection()?;
|
||||||
tokio::spawn(connection);
|
tokio::spawn(connection);
|
||||||
|
|
||||||
let ip: IpNetwork = network.ipv4.parse()?;
|
let ipnet: IpNetwork = network.ipv4.address.parse()?;
|
||||||
|
let gateway: Ipv4Addr = network.ipv4.gateway.parse()?;
|
||||||
|
|
||||||
let mut links = handle
|
let mut links = handle
|
||||||
.link()
|
.link()
|
||||||
@ -302,17 +304,11 @@ impl ContainerInit {
|
|||||||
if let Some(link) = links.try_next().await? {
|
if let Some(link) = links.try_next().await? {
|
||||||
handle
|
handle
|
||||||
.address()
|
.address()
|
||||||
.add(link.header.index, ip.ip(), ip.prefix())
|
.add(link.header.index, ipnet.ip(), ipnet.prefix())
|
||||||
.execute()
|
.execute()
|
||||||
.await?;
|
.await?;
|
||||||
|
|
||||||
handle
|
handle.link().set(link.header.index).up().execute().await?;
|
||||||
.link()
|
|
||||||
.set(link.header.index)
|
|
||||||
.arp(false)
|
|
||||||
.up()
|
|
||||||
.execute()
|
|
||||||
.await?;
|
|
||||||
|
|
||||||
handle
|
handle
|
||||||
.route()
|
.route()
|
||||||
@ -320,6 +316,7 @@ impl ContainerInit {
|
|||||||
.v4()
|
.v4()
|
||||||
.destination_prefix(Ipv4Addr::new(0, 0, 0, 0), 0)
|
.destination_prefix(Ipv4Addr::new(0, 0, 0, 0), 0)
|
||||||
.output_interface(link.header.index)
|
.output_interface(link.header.index)
|
||||||
|
.gateway(gateway)
|
||||||
.execute()
|
.execute()
|
||||||
.await?;
|
.await?;
|
||||||
} else {
|
} else {
|
||||||
|
@ -7,7 +7,7 @@ use crate::image::name::ImageName;
|
|||||||
use crate::image::{ImageCompiler, ImageInfo};
|
use crate::image::{ImageCompiler, ImageInfo};
|
||||||
use advmac::MacAddr6;
|
use advmac::MacAddr6;
|
||||||
use anyhow::{anyhow, Result};
|
use anyhow::{anyhow, Result};
|
||||||
use hypha::{LaunchInfo, LaunchNetwork};
|
use hypha::{LaunchInfo, LaunchNetwork, LaunchNetworkIpv4};
|
||||||
use ipnetwork::Ipv4Network;
|
use ipnetwork::Ipv4Network;
|
||||||
use loopdev::LoopControl;
|
use loopdev::LoopControl;
|
||||||
use std::io::{Read, Write};
|
use std::io::{Read, Write};
|
||||||
@ -85,7 +85,10 @@ impl Controller {
|
|||||||
let launch_config = LaunchInfo {
|
let launch_config = LaunchInfo {
|
||||||
network: Some(LaunchNetwork {
|
network: Some(LaunchNetwork {
|
||||||
link: "eth0".to_string(),
|
link: "eth0".to_string(),
|
||||||
ipv4: format!("{}/24", ipv4),
|
ipv4: LaunchNetworkIpv4 {
|
||||||
|
address: format!("{}/24", ipv4),
|
||||||
|
gateway: "192.168.42.1".to_string(),
|
||||||
|
},
|
||||||
}),
|
}),
|
||||||
env,
|
env,
|
||||||
run,
|
run,
|
||||||
|
@ -1,7 +1,6 @@
|
|||||||
use std::net::{IpAddr, Ipv4Addr, Ipv6Addr, SocketAddr};
|
use std::net::{IpAddr, Ipv4Addr, Ipv6Addr, SocketAddr};
|
||||||
|
|
||||||
use etherparse::{Ethernet2Header, IpHeader, PacketHeaders, TcpHeader, UdpHeader, WriteError};
|
use etherparse::{Ethernet2Header, IpHeader, PacketHeaders, TcpHeader, UdpHeader, WriteError};
|
||||||
use tracing::debug;
|
|
||||||
|
|
||||||
use crate::error::IpStackError;
|
use crate::error::IpStackError;
|
||||||
|
|
||||||
@ -42,7 +41,6 @@ pub struct NetworkPacket {
|
|||||||
|
|
||||||
impl NetworkPacket {
|
impl NetworkPacket {
|
||||||
pub fn parse(buf: &[u8]) -> Result<Self, IpStackError> {
|
pub fn parse(buf: &[u8]) -> Result<Self, IpStackError> {
|
||||||
debug!("read: {:?}", buf);
|
|
||||||
let p = PacketHeaders::from_ethernet_slice(buf).map_err(|_| IpStackError::InvalidPacket)?;
|
let p = PacketHeaders::from_ethernet_slice(buf).map_err(|_| IpStackError::InvalidPacket)?;
|
||||||
let ip = p.ip.ok_or(IpStackError::InvalidPacket)?;
|
let ip = p.ip.ok_or(IpStackError::InvalidPacket)?;
|
||||||
let transport = match p.transport {
|
let transport = match p.transport {
|
||||||
@ -139,7 +137,6 @@ impl NetworkPacket {
|
|||||||
// .write(&mut buf)
|
// .write(&mut buf)
|
||||||
// .map_err(IpStackError::PacketWriteError)?;
|
// .map_err(IpStackError::PacketWriteError)?;
|
||||||
buf.extend_from_slice(&self.payload);
|
buf.extend_from_slice(&self.payload);
|
||||||
debug!("write: {:?}", buf);
|
|
||||||
Ok(buf)
|
Ok(buf)
|
||||||
}
|
}
|
||||||
pub fn ttl(&self) -> u8 {
|
pub fn ttl(&self) -> u8 {
|
||||||
|
@ -15,6 +15,7 @@ tokio = { workspace = true }
|
|||||||
futures = { workspace = true }
|
futures = { workspace = true }
|
||||||
libc = { workspace = true }
|
libc = { workspace = true }
|
||||||
udp-stream = { workspace = true }
|
udp-stream = { workspace = true }
|
||||||
|
smoltcp = { workspace = true }
|
||||||
|
|
||||||
[dependencies.advmac]
|
[dependencies.advmac]
|
||||||
path = "../libs/advmac"
|
path = "../libs/advmac"
|
||||||
|
@ -1,21 +1,32 @@
|
|||||||
|
use std::os::fd::AsRawFd;
|
||||||
|
use std::str::FromStr;
|
||||||
use std::sync::{Arc, Mutex};
|
use std::sync::{Arc, Mutex};
|
||||||
|
use std::thread;
|
||||||
use std::time::Duration;
|
use std::time::Duration;
|
||||||
|
|
||||||
|
use advmac::MacAddr6;
|
||||||
use anyhow::{anyhow, Result};
|
use anyhow::{anyhow, Result};
|
||||||
use futures::TryStreamExt;
|
use futures::channel::oneshot;
|
||||||
|
use futures::{try_join, TryStreamExt};
|
||||||
use ipstack::stream::IpStackStream;
|
use ipstack::stream::IpStackStream;
|
||||||
use log::{debug, error, info, warn};
|
use log::{debug, error, info, warn};
|
||||||
use netlink_packet_route::link::LinkAttribute;
|
use netlink_packet_route::link::LinkAttribute;
|
||||||
use raw_socket::{AsyncRawSocket, RawSocket};
|
use raw_socket::{AsyncRawSocket, RawSocket};
|
||||||
|
use smoltcp::iface::{Config, Interface, SocketSet};
|
||||||
|
use smoltcp::time::Instant;
|
||||||
|
use smoltcp::wire::{HardwareAddress, IpCidr};
|
||||||
use tokio::net::TcpStream;
|
use tokio::net::TcpStream;
|
||||||
use tokio::time::sleep;
|
use tokio::time::sleep;
|
||||||
use udp_stream::UdpStream;
|
use udp_stream::UdpStream;
|
||||||
|
|
||||||
mod raw_socket;
|
mod raw_socket;
|
||||||
|
|
||||||
|
#[derive(Clone)]
|
||||||
pub struct NetworkBackend {
|
pub struct NetworkBackend {
|
||||||
|
pub network: String,
|
||||||
pub interface: String,
|
pub interface: String,
|
||||||
}
|
}
|
||||||
|
|
||||||
pub struct NetworkService {
|
pub struct NetworkService {
|
||||||
pub network: String,
|
pub network: String,
|
||||||
}
|
}
|
||||||
@ -27,8 +38,9 @@ impl NetworkService {
|
|||||||
}
|
}
|
||||||
|
|
||||||
impl NetworkBackend {
|
impl NetworkBackend {
|
||||||
pub fn new(iface: &str) -> Result<NetworkBackend> {
|
pub fn new(network: &str, iface: &str) -> Result<NetworkBackend> {
|
||||||
Ok(NetworkBackend {
|
Ok(NetworkBackend {
|
||||||
|
network: network.to_string(),
|
||||||
interface: iface.to_string(),
|
interface: iface.to_string(),
|
||||||
})
|
})
|
||||||
}
|
}
|
||||||
@ -56,14 +68,16 @@ impl NetworkBackend {
|
|||||||
}
|
}
|
||||||
|
|
||||||
pub async fn run(&mut self) -> Result<()> {
|
pub async fn run(&mut self) -> Result<()> {
|
||||||
|
try_join!(self.run_internet_stack(), self.run_virtual_host_stack()).map(|_| ())
|
||||||
|
}
|
||||||
|
|
||||||
|
async fn run_internet_stack(&self) -> Result<()> {
|
||||||
let mut config = ipstack::IpStackConfig::default();
|
let mut config = ipstack::IpStackConfig::default();
|
||||||
config.mtu(1500);
|
config.mtu(1500);
|
||||||
config.tcp_timeout(std::time::Duration::from_secs(600)); // 10 minutes
|
config.tcp_timeout(std::time::Duration::from_secs(600));
|
||||||
config.udp_timeout(std::time::Duration::from_secs(10)); // 10 seconds
|
config.udp_timeout(std::time::Duration::from_secs(10));
|
||||||
|
|
||||||
let mut socket = RawSocket::new(&self.interface)?;
|
let socket = AsyncRawSocket::bind(&self.interface)?;
|
||||||
socket.bind_interface()?;
|
|
||||||
let socket = AsyncRawSocket::new(socket)?;
|
|
||||||
let mut stack = ipstack::IpStack::new(config, socket);
|
let mut stack = ipstack::IpStack::new(config, socket);
|
||||||
|
|
||||||
while let Ok(stream) = stack.accept().await {
|
while let Ok(stream) = stack.accept().await {
|
||||||
@ -72,7 +86,40 @@ impl NetworkBackend {
|
|||||||
Ok(())
|
Ok(())
|
||||||
}
|
}
|
||||||
|
|
||||||
async fn process_stream(&mut self, stream: IpStackStream) -> Result<()> {
|
async fn run_virtual_host_stack(&self) -> Result<()> {
|
||||||
|
let (tx, rx) = oneshot::channel();
|
||||||
|
let me = self.clone();
|
||||||
|
thread::spawn(move || {
|
||||||
|
let _ = tx.send(me.run_virtual_host_stack_blocking());
|
||||||
|
});
|
||||||
|
rx.await?
|
||||||
|
}
|
||||||
|
|
||||||
|
fn run_virtual_host_stack_blocking(&self) -> Result<()> {
|
||||||
|
let address = IpCidr::from_str(&self.network)
|
||||||
|
.map_err(|_| anyhow!("failed to parse cidr: {}", self.network))?;
|
||||||
|
let addresses: Vec<IpCidr> = vec![address];
|
||||||
|
let mut socket = RawSocket::new(&self.interface)?;
|
||||||
|
let mac = MacAddr6::random();
|
||||||
|
let mac = HardwareAddress::Ethernet(smoltcp::wire::EthernetAddress(mac.to_array()));
|
||||||
|
let config = Config::new(mac);
|
||||||
|
let mut iface = Interface::new(config, &mut socket, Instant::now());
|
||||||
|
iface.update_ip_addrs(|addrs| {
|
||||||
|
addrs
|
||||||
|
.extend_from_slice(&addresses)
|
||||||
|
.expect("failed to set ip addresses");
|
||||||
|
});
|
||||||
|
|
||||||
|
let mut sockets = SocketSet::new(vec![]);
|
||||||
|
let fd = socket.as_raw_fd();
|
||||||
|
loop {
|
||||||
|
let timestamp = Instant::now();
|
||||||
|
iface.poll(timestamp, &mut socket, &mut sockets);
|
||||||
|
smoltcp::phy::wait(fd, iface.poll_delay(timestamp, &sockets))?;
|
||||||
|
}
|
||||||
|
}
|
||||||
|
|
||||||
|
async fn process_stream(&self, stream: IpStackStream) -> Result<()> {
|
||||||
match stream {
|
match stream {
|
||||||
IpStackStream::Tcp(mut tcp) => {
|
IpStackStream::Tcp(mut tcp) => {
|
||||||
debug!("tcp: {}", tcp.peer_addr());
|
debug!("tcp: {}", tcp.peer_addr());
|
||||||
@ -160,7 +207,7 @@ impl NetworkService {
|
|||||||
spawned: Arc<Mutex<Vec<String>>>,
|
spawned: Arc<Mutex<Vec<String>>>,
|
||||||
) -> Result<()> {
|
) -> Result<()> {
|
||||||
let interface = interface.to_string();
|
let interface = interface.to_string();
|
||||||
let mut network = NetworkBackend::new(&interface)?;
|
let mut network = NetworkBackend::new(&self.network, &interface)?;
|
||||||
info!("initializing network backend for interface {}", interface);
|
info!("initializing network backend for interface {}", interface);
|
||||||
network.init().await?;
|
network.init().await?;
|
||||||
tokio::time::sleep(Duration::from_secs(1)).await;
|
tokio::time::sleep(Duration::from_secs(1)).await;
|
||||||
|
@ -1,30 +1,35 @@
|
|||||||
|
use anyhow::Result;
|
||||||
use futures::ready;
|
use futures::ready;
|
||||||
|
use log::debug;
|
||||||
|
use smoltcp::phy::{Device, DeviceCapabilities, Medium};
|
||||||
|
use smoltcp::time::Instant;
|
||||||
|
use std::cell::RefCell;
|
||||||
use std::os::unix::io::{AsRawFd, RawFd};
|
use std::os::unix::io::{AsRawFd, RawFd};
|
||||||
use std::pin::Pin;
|
use std::pin::Pin;
|
||||||
|
use std::rc::Rc;
|
||||||
use std::task::{Context, Poll};
|
use std::task::{Context, Poll};
|
||||||
use std::{io, mem};
|
use std::{io, mem};
|
||||||
|
|
||||||
use anyhow::Result;
|
|
||||||
use tokio::io::unix::AsyncFd;
|
use tokio::io::unix::AsyncFd;
|
||||||
use tokio::io::{AsyncRead, AsyncWrite, ReadBuf};
|
use tokio::io::{AsyncRead, AsyncWrite, ReadBuf};
|
||||||
|
|
||||||
const SIOCGIFINDEX: libc::c_ulong = 0x8933;
|
const SIOCGIFINDEX: libc::c_ulong = 0x8933;
|
||||||
|
|
||||||
#[derive(Debug)]
|
#[derive(Debug)]
|
||||||
pub struct RawSocket {
|
pub struct RawSocketHandle {
|
||||||
|
pub mtu: usize,
|
||||||
protocol: libc::c_short,
|
protocol: libc::c_short,
|
||||||
lower: libc::c_int,
|
lower: libc::c_int,
|
||||||
ifreq: Ifreq,
|
ifreq: Ifreq,
|
||||||
}
|
}
|
||||||
|
|
||||||
impl AsRawFd for RawSocket {
|
impl AsRawFd for RawSocketHandle {
|
||||||
fn as_raw_fd(&self) -> RawFd {
|
fn as_raw_fd(&self) -> RawFd {
|
||||||
self.lower
|
self.lower
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
|
|
||||||
impl RawSocket {
|
impl RawSocketHandle {
|
||||||
pub fn new(name: &str) -> io::Result<RawSocket> {
|
pub fn new(interface: &str) -> io::Result<RawSocketHandle> {
|
||||||
let protocol: libc::c_short = 0x0003;
|
let protocol: libc::c_short = 0x0003;
|
||||||
let lower = unsafe {
|
let lower = unsafe {
|
||||||
let lower = libc::socket(
|
let lower = libc::socket(
|
||||||
@ -38,13 +43,20 @@ impl RawSocket {
|
|||||||
lower
|
lower
|
||||||
};
|
};
|
||||||
|
|
||||||
Ok(RawSocket {
|
Ok(RawSocketHandle {
|
||||||
|
mtu: 1500,
|
||||||
protocol,
|
protocol,
|
||||||
lower,
|
lower,
|
||||||
ifreq: ifreq_for(name),
|
ifreq: ifreq_for(interface),
|
||||||
})
|
})
|
||||||
}
|
}
|
||||||
|
|
||||||
|
pub fn bind(interface: &str) -> Result<Self> {
|
||||||
|
let mut socket = RawSocketHandle::new(interface)?;
|
||||||
|
socket.bind_interface()?;
|
||||||
|
Ok(socket)
|
||||||
|
}
|
||||||
|
|
||||||
pub fn bind_interface(&mut self) -> io::Result<()> {
|
pub fn bind_interface(&mut self) -> io::Result<()> {
|
||||||
let sockaddr = libc::sockaddr_ll {
|
let sockaddr = libc::sockaddr_ll {
|
||||||
sll_family: libc::AF_PACKET as u16,
|
sll_family: libc::AF_PACKET as u16,
|
||||||
@ -101,7 +113,7 @@ impl RawSocket {
|
|||||||
}
|
}
|
||||||
}
|
}
|
||||||
|
|
||||||
impl Drop for RawSocket {
|
impl Drop for RawSocketHandle {
|
||||||
fn drop(&mut self) {
|
fn drop(&mut self) {
|
||||||
unsafe {
|
unsafe {
|
||||||
libc::close(self.lower);
|
libc::close(self.lower);
|
||||||
@ -109,6 +121,107 @@ impl Drop for RawSocket {
|
|||||||
}
|
}
|
||||||
}
|
}
|
||||||
|
|
||||||
|
#[derive(Debug)]
|
||||||
|
pub struct RawSocket {
|
||||||
|
lower: Rc<RefCell<RawSocketHandle>>,
|
||||||
|
mtu: usize,
|
||||||
|
}
|
||||||
|
|
||||||
|
impl AsRawFd for RawSocket {
|
||||||
|
fn as_raw_fd(&self) -> RawFd {
|
||||||
|
self.lower.borrow().as_raw_fd()
|
||||||
|
}
|
||||||
|
}
|
||||||
|
|
||||||
|
impl RawSocket {
|
||||||
|
pub fn new(name: &str) -> io::Result<RawSocket> {
|
||||||
|
let mut lower = RawSocketHandle::new(name)?;
|
||||||
|
lower.bind_interface()?;
|
||||||
|
let mtu = lower.mtu;
|
||||||
|
Ok(RawSocket {
|
||||||
|
lower: Rc::new(RefCell::new(lower)),
|
||||||
|
mtu,
|
||||||
|
})
|
||||||
|
}
|
||||||
|
}
|
||||||
|
|
||||||
|
impl Device for RawSocket {
|
||||||
|
type RxToken<'a> = RxToken
|
||||||
|
where
|
||||||
|
Self: 'a;
|
||||||
|
type TxToken<'a> = TxToken
|
||||||
|
where
|
||||||
|
Self: 'a;
|
||||||
|
|
||||||
|
fn capabilities(&self) -> DeviceCapabilities {
|
||||||
|
let mut capabilities = DeviceCapabilities::default();
|
||||||
|
capabilities.medium = Medium::Ethernet;
|
||||||
|
capabilities.max_transmission_unit = self.mtu;
|
||||||
|
capabilities
|
||||||
|
}
|
||||||
|
|
||||||
|
fn receive(&mut self, _timestamp: Instant) -> Option<(Self::RxToken<'_>, Self::TxToken<'_>)> {
|
||||||
|
let lower = self.lower.borrow_mut();
|
||||||
|
let mut buffer = vec![0; self.mtu];
|
||||||
|
match lower.recv(&mut buffer[..]) {
|
||||||
|
Ok(size) => {
|
||||||
|
buffer.resize(size, 0);
|
||||||
|
let rx = RxToken { buffer };
|
||||||
|
let tx = TxToken {
|
||||||
|
lower: self.lower.clone(),
|
||||||
|
};
|
||||||
|
Some((rx, tx))
|
||||||
|
}
|
||||||
|
Err(err) if err.kind() == io::ErrorKind::WouldBlock => None,
|
||||||
|
Err(err) => panic!("{}", err),
|
||||||
|
}
|
||||||
|
}
|
||||||
|
|
||||||
|
fn transmit(&mut self, _timestamp: Instant) -> Option<Self::TxToken<'_>> {
|
||||||
|
Some(TxToken {
|
||||||
|
lower: self.lower.clone(),
|
||||||
|
})
|
||||||
|
}
|
||||||
|
}
|
||||||
|
|
||||||
|
#[doc(hidden)]
|
||||||
|
pub struct RxToken {
|
||||||
|
buffer: Vec<u8>,
|
||||||
|
}
|
||||||
|
|
||||||
|
impl smoltcp::phy::RxToken for RxToken {
|
||||||
|
fn consume<R, F>(mut self, f: F) -> R
|
||||||
|
where
|
||||||
|
F: FnOnce(&mut [u8]) -> R,
|
||||||
|
{
|
||||||
|
f(&mut self.buffer[..])
|
||||||
|
}
|
||||||
|
}
|
||||||
|
|
||||||
|
#[doc(hidden)]
|
||||||
|
pub struct TxToken {
|
||||||
|
lower: Rc<RefCell<RawSocketHandle>>,
|
||||||
|
}
|
||||||
|
|
||||||
|
impl smoltcp::phy::TxToken for TxToken {
|
||||||
|
fn consume<R, F>(self, len: usize, f: F) -> R
|
||||||
|
where
|
||||||
|
F: FnOnce(&mut [u8]) -> R,
|
||||||
|
{
|
||||||
|
let lower = self.lower.borrow_mut();
|
||||||
|
let mut buffer = vec![0; len];
|
||||||
|
let result = f(&mut buffer);
|
||||||
|
match lower.send(&buffer[..]) {
|
||||||
|
Ok(_) => {}
|
||||||
|
Err(err) if err.kind() == io::ErrorKind::WouldBlock => {
|
||||||
|
debug!("phy: tx failed due to WouldBlock")
|
||||||
|
}
|
||||||
|
Err(err) => panic!("{}", err),
|
||||||
|
}
|
||||||
|
result
|
||||||
|
}
|
||||||
|
}
|
||||||
|
|
||||||
#[repr(C)]
|
#[repr(C)]
|
||||||
#[derive(Debug)]
|
#[derive(Debug)]
|
||||||
struct Ifreq {
|
struct Ifreq {
|
||||||
@ -143,15 +256,20 @@ fn ifreq_ioctl(
|
|||||||
}
|
}
|
||||||
|
|
||||||
pub struct AsyncRawSocket {
|
pub struct AsyncRawSocket {
|
||||||
inner: AsyncFd<RawSocket>,
|
inner: AsyncFd<RawSocketHandle>,
|
||||||
}
|
}
|
||||||
|
|
||||||
impl AsyncRawSocket {
|
impl AsyncRawSocket {
|
||||||
pub fn new(socket: RawSocket) -> Result<Self> {
|
pub fn new(socket: RawSocketHandle) -> Result<Self> {
|
||||||
Ok(Self {
|
Ok(Self {
|
||||||
inner: AsyncFd::new(socket)?,
|
inner: AsyncFd::new(socket)?,
|
||||||
})
|
})
|
||||||
}
|
}
|
||||||
|
|
||||||
|
pub fn bind(interface: &str) -> Result<Self> {
|
||||||
|
let socket = RawSocketHandle::bind(interface)?;
|
||||||
|
AsyncRawSocket::new(socket)
|
||||||
|
}
|
||||||
}
|
}
|
||||||
|
|
||||||
impl AsyncRead for AsyncRawSocket {
|
impl AsyncRead for AsyncRawSocket {
|
||||||
|
@ -1,9 +1,15 @@
|
|||||||
use serde::{Deserialize, Serialize};
|
use serde::{Deserialize, Serialize};
|
||||||
|
|
||||||
|
#[derive(Serialize, Deserialize, Debug)]
|
||||||
|
pub struct LaunchNetworkIpv4 {
|
||||||
|
pub address: String,
|
||||||
|
pub gateway: String,
|
||||||
|
}
|
||||||
|
|
||||||
#[derive(Serialize, Deserialize, Debug)]
|
#[derive(Serialize, Deserialize, Debug)]
|
||||||
pub struct LaunchNetwork {
|
pub struct LaunchNetwork {
|
||||||
pub link: String,
|
pub link: String,
|
||||||
pub ipv4: String,
|
pub ipv4: LaunchNetworkIpv4,
|
||||||
}
|
}
|
||||||
|
|
||||||
#[derive(Serialize, Deserialize, Debug)]
|
#[derive(Serialize, Deserialize, Debug)]
|
||||||
|
Reference in New Issue
Block a user