294 lines
8.8 KiB
Rust
Raw Normal View History

2017-10-30 10:22:38 +01:00
// Copyright 2017 Parity Technologies (UK) Ltd.
//
// Permission is hereby granted, free of charge, to any person obtaining a
// copy of this software and associated documentation files (the "Software"),
// to deal in the Software without restriction, including without limitation
// the rights to use, copy, modify, merge, publish, distribute, sublicense,
// and/or sell copies of the Software, and to permit persons to whom the
// Software is furnished to do so, subject to the following conditions:
//
// The above copyright notice and this permission notice shall be included in
// all copies or substantial portions of the Software.
//
// THE SOFTWARE IS PROVIDED "AS IS", WITHOUT WARRANTY OF ANY KIND, EXPRESS
// OR IMPLIED, INCLUDING BUT NOT LIMITED TO THE WARRANTIES OF MERCHANTABILITY,
// FITNESS FOR A PARTICULAR PURPOSE AND NONINFRINGEMENT. IN NO EVENT SHALL THE
// AUTHORS OR COPYRIGHT HOLDERS BE LIABLE FOR ANY CLAIM, DAMAGES OR OTHER
// LIABILITY, WHETHER IN AN ACTION OF CONTRACT, TORT OR OTHERWISE, ARISING
// FROM, OUT OF OR IN CONNECTION WITH THE SOFTWARE OR THE USE OR OTHER
// DEALINGS IN THE SOFTWARE.
//! The `secio` protocol is a middleware that will encrypt and decrypt communications going
//! through a socket (or anything that implements `AsyncRead + AsyncWrite`).
//!
2017-12-07 15:34:22 +01:00
//! # Connection upgrade
//!
2017-12-07 15:34:22 +01:00
//! The `SecioConfig` struct implements the `ConnectionUpgrade` trait. You can apply it over a
//! `Transport` by using the `with_upgrade` method. The returned object will also implement
//! `Transport` and will automatically apply the secio protocol over any connection that is opened
//! through it.
//!
2017-12-07 15:34:22 +01:00
//! ```no_run
//! extern crate futures;
//! extern crate tokio_core;
//! extern crate tokio_io;
//! extern crate libp2p_core;
2017-12-07 15:34:22 +01:00
//! extern crate libp2p_secio;
//! extern crate libp2p_tcp_transport;
//!
2017-12-07 15:34:22 +01:00
//! # fn main() {
//! use futures::Future;
//! use libp2p_secio::{SecioConfig, SecioKeyPair};
//! use libp2p_core::{Multiaddr, Transport, upgrade};
2017-12-07 15:34:22 +01:00
//! use libp2p_tcp_transport::TcpConfig;
//! use tokio_core::reactor::Core;
//! use tokio_io::io::write_all;
//!
2017-12-07 15:34:22 +01:00
//! let mut core = Core::new().unwrap();
//!
2017-12-07 15:34:22 +01:00
//! let transport = TcpConfig::new(core.handle())
//! .with_upgrade({
//! # let private_key = b"";
//! //let private_key = include_bytes!("test-private-key.pk8");
//! # let public_key = vec![];
//! //let public_key = include_bytes!("test-public-key.der").to_vec();
//! let upgrade = SecioConfig {
//! // See the documentation of `SecioKeyPair`.
//! key: SecioKeyPair::rsa_from_pkcs8(private_key, public_key).unwrap(),
//! };
//!
//! upgrade::map(upgrade, |(socket, _remote_key)| socket)
//! });
//!
//! let future = transport.dial("/ip4/127.0.0.1/tcp/12345".parse::<Multiaddr>().unwrap())
//! .unwrap_or_else(|_| panic!("Unable to dial node"))
//! .and_then(|(connection, _)| {
//! // Sends "hello world" on the connection, will be encrypted.
//! write_all(connection, "hello world")
//! });
//!
2017-12-07 15:34:22 +01:00
//! core.run(future).unwrap();
//! # }
//! ```
//!
//! # Manual usage
//!
//! > **Note**: You are encouraged to use `SecioConfig` as described above.
//!
2017-10-30 10:22:38 +01:00
//! You can add the `secio` layer over a socket by calling `SecioMiddleware::handshake()`. This
//! method will perform a handshake with the host, and return a future that corresponds to the
//! moment when the handshake succeeds or errored. On success, the future produces a
//! `SecioMiddleware` that implements `Sink` and `Stream` and can be used to send packets of data.
2017-11-02 11:58:02 +01:00
//!
2017-10-30 10:22:38 +01:00
extern crate bytes;
extern crate crypto;
extern crate futures;
extern crate libp2p_core;
2018-02-14 13:02:56 +01:00
#[macro_use]
extern crate log;
2017-10-30 10:22:38 +01:00
extern crate protobuf;
extern crate rand;
extern crate ring;
2017-11-02 11:58:02 +01:00
extern crate rw_stream_sink;
2017-10-30 10:22:38 +01:00
extern crate tokio_io;
extern crate untrusted;
pub use self::error::SecioError;
2017-11-02 11:58:02 +01:00
use bytes::{Bytes, BytesMut};
use futures::stream::MapErr as StreamMapErr;
use futures::{Future, Poll, Sink, StartSend, Stream};
use libp2p_core::Multiaddr;
2017-10-30 10:22:38 +01:00
use ring::signature::RSAKeyPair;
2017-11-02 11:58:02 +01:00
use rw_stream_sink::RwStreamSink;
2017-12-04 15:39:40 +01:00
use std::error::Error;
2017-11-02 11:58:02 +01:00
use std::io::{Error as IoError, ErrorKind as IoErrorKind};
use std::iter;
2017-10-30 10:22:38 +01:00
use std::sync::Arc;
use tokio_io::{AsyncRead, AsyncWrite};
2017-12-04 15:39:40 +01:00
use untrusted::Input;
2017-10-30 10:22:38 +01:00
mod algo_support;
mod codec;
mod error;
mod handshake;
mod keys_proto;
2017-10-30 10:22:38 +01:00
mod structs_proto;
/// Implementation of the `ConnectionUpgrade` trait of `libp2p_core`. Automatically applies
2017-11-02 11:58:02 +01:00
/// secio on any connection.
#[derive(Clone)]
2017-12-04 15:50:14 +01:00
pub struct SecioConfig {
/// Private and public keys of the local node.
pub key: SecioKeyPair,
2017-11-02 11:58:02 +01:00
}
2017-12-04 15:39:40 +01:00
/// Private and public keys of the local node.
///
/// # Generating offline keys with OpenSSL
///
/// ## RSA
///
/// Generating the keys:
///
/// ```ignore
/// openssl genrsa -out private.pem 2048
/// openssl rsa -in private.pem -outform DER -pubout -out public.der
/// openssl pkcs8 -in private.pem -topk8 -nocrypt -out private.pk8
/// rm private.pem # optional
/// ```
///
/// Loading the keys:
///
/// ```ignore
2017-12-07 12:05:38 +01:00
/// let key_pair = SecioKeyPair::rsa_from_pkcs8(include_bytes!("private.pk8"),
/// include_bytes!("public.der"));
2017-12-04 15:39:40 +01:00
/// ```
///
#[derive(Clone)]
pub struct SecioKeyPair {
inner: SecioKeyPairInner,
2017-12-04 15:39:40 +01:00
}
impl SecioKeyPair {
pub fn rsa_from_pkcs8<P>(
private: &[u8],
public: P,
) -> Result<SecioKeyPair, Box<Error + Send + Sync>>
where
P: Into<Vec<u8>>,
{
let private =
RSAKeyPair::from_pkcs8(Input::from(&private[..])).map_err(|err| Box::new(err))?;
2017-12-04 15:39:40 +01:00
Ok(SecioKeyPair {
inner: SecioKeyPairInner::Rsa {
public: public.into(),
private: Arc::new(private),
},
})
}
2017-12-04 15:39:40 +01:00
}
// Inner content of `SecioKeyPair`.
#[derive(Clone)]
enum SecioKeyPairInner {
Rsa {
public: Vec<u8>,
private: Arc<RSAKeyPair>,
},
2017-12-04 15:39:40 +01:00
}
#[derive(Debug, Clone)]
pub enum SecioPublicKey {
/// DER format.
Rsa(Vec<u8>),
2017-11-02 11:58:02 +01:00
}
impl<S> libp2p_core::ConnectionUpgrade<S> for SecioConfig
where
S: AsyncRead + AsyncWrite + 'static,
2017-11-02 11:58:02 +01:00
{
type Output = (
RwStreamSink<StreamMapErr<SecioMiddleware<S>, fn(SecioError) -> IoError>>,
SecioPublicKey,
);
type Future = Box<Future<Item = Self::Output, Error = IoError>>;
type NamesIter = iter::Once<(Bytes, ())>;
type UpgradeIdentifier = ();
2017-11-02 11:58:02 +01:00
#[inline]
fn protocol_names(&self) -> Self::NamesIter {
iter::once(("/secio/1.0.0".into(), ()))
}
2017-11-02 11:58:02 +01:00
#[inline]
fn upgrade(
self,
incoming: S,
_: (),
_: libp2p_core::Endpoint,
remote_addr: &Multiaddr,
) -> Self::Future {
info!(target: "libp2p-secio", "starting secio upgrade with {:?}", remote_addr);
2018-02-14 13:02:56 +01:00
let fut = SecioMiddleware::handshake(incoming, self.key);
let wrapped = fut.map(|(stream_sink, pubkey)| {
let mapped = stream_sink.map_err(map_err as fn(_) -> _);
(RwStreamSink::new(mapped), pubkey)
}).map_err(map_err);
Box::new(wrapped)
}
2017-11-02 11:58:02 +01:00
}
#[inline]
fn map_err(err: SecioError) -> IoError {
debug!(target: "libp2p-secio", "error during secio handshake {:?}", err);
IoError::new(IoErrorKind::InvalidData, err)
2017-11-02 11:58:02 +01:00
}
2017-10-30 10:22:38 +01:00
/// Wraps around an object that implements `AsyncRead` and `AsyncWrite`.
///
/// Implements `Sink` and `Stream` whose items are frames of data. Each frame is encoded
/// individually, so you are encouraged to group data in few frames if possible.
pub struct SecioMiddleware<S> {
inner: codec::FullCodec<S>,
2017-10-30 10:22:38 +01:00
}
impl<S> SecioMiddleware<S>
where
S: AsyncRead + AsyncWrite,
2017-10-30 10:22:38 +01:00
{
/// Attempts to perform a handshake on the given socket.
///
/// On success, produces a `SecioMiddleware` that can then be used to encode/decode
/// communications.
pub fn handshake<'a>(
socket: S,
key_pair: SecioKeyPair,
) -> Box<Future<Item = (SecioMiddleware<S>, SecioPublicKey), Error = SecioError> + 'a>
where
S: 'a,
{
let SecioKeyPairInner::Rsa { private, public } = key_pair.inner;
2017-12-04 15:39:40 +01:00
let fut = handshake::handshake(socket, public, private).map(|(inner, pubkey)| {
let inner = SecioMiddleware { inner };
(inner, SecioPublicKey::Rsa(pubkey))
});
Box::new(fut)
}
2017-10-30 10:22:38 +01:00
}
impl<S> Sink for SecioMiddleware<S>
where
S: AsyncRead + AsyncWrite,
2017-10-30 10:22:38 +01:00
{
type SinkItem = BytesMut;
type SinkError = IoError;
2017-10-30 10:22:38 +01:00
#[inline]
fn start_send(&mut self, item: Self::SinkItem) -> StartSend<Self::SinkItem, Self::SinkError> {
self.inner.start_send(item)
}
2017-10-30 10:22:38 +01:00
#[inline]
fn poll_complete(&mut self) -> Poll<(), Self::SinkError> {
self.inner.poll_complete()
}
2017-10-30 10:22:38 +01:00
}
impl<S> Stream for SecioMiddleware<S>
where
S: AsyncRead + AsyncWrite,
2017-10-30 10:22:38 +01:00
{
type Item = Vec<u8>;
type Error = SecioError;
2017-10-30 10:22:38 +01:00
#[inline]
fn poll(&mut self) -> Poll<Option<Self::Item>, Self::Error> {
self.inner.poll()
}
2017-10-30 10:22:38 +01:00
}