use failure::*; use http::Uri; use hyper::Body; use hyper::client::Client; use xdg::BaseDirectories; use chrono::{DateTime, Utc}; use std::collections::HashSet; use std::sync::{Arc, Mutex}; use std::io::Write; use http::{Request, Response}; use http::header::HeaderValue; use futures::*; use futures::stream::Stream; use std::sync::atomic::{AtomicUsize, Ordering}; use tokio::sync::mpsc; use openssl::ssl::{SslConnector, SslMethod}; use serde_json::{json, Value}; use url::percent_encoding::{percent_encode, DEFAULT_ENCODE_SET}; use crate::tools::{self, BroadcastFuture, tty}; use crate::tools::futures::{cancellable, Canceller}; use super::pipe_to_stream::*; use super::merge_known_chunks::*; use crate::backup::*; #[derive(Clone)] struct AuthInfo { username: String, ticket: String, token: String, } /// HTTP(S) API client pub struct HttpClient { client: Client>, server: String, auth: BroadcastFuture, } fn store_ticket_info(server: &str, username: &str, ticket: &str, token: &str) -> Result<(), Error> { let base = BaseDirectories::with_prefix("proxmox-backup")?; // usually /run/user//... let path = base.place_runtime_file("tickets")?; let mode = nix::sys::stat::Mode::from_bits_truncate(0o0600); let mut data = tools::file_get_json(&path, Some(json!({})))?; let now = Utc::now().timestamp(); data[server][username] = json!({ "timestamp": now, "ticket": ticket, "token": token}); let mut new_data = json!({}); let ticket_lifetime = tools::ticket::TICKET_LIFETIME - 60; let empty = serde_json::map::Map::new(); for (server, info) in data.as_object().unwrap_or(&empty) { for (_user, uinfo) in info.as_object().unwrap_or(&empty) { if let Some(timestamp) = uinfo["timestamp"].as_i64() { let age = now - timestamp; if age < ticket_lifetime { new_data[server][username] = uinfo.clone(); } } } } tools::file_set_contents(path, new_data.to_string().as_bytes(), Some(mode))?; Ok(()) } fn load_ticket_info(server: &str, username: &str) -> Option<(String, String)> { let base = match BaseDirectories::with_prefix("proxmox-backup") { Ok(b) => b, _ => return None, }; // usually /run/user//... let path = match base.place_runtime_file("tickets") { Ok(p) => p, _ => return None, }; let data = match tools::file_get_json(&path, None) { Ok(v) => v, _ => return None, }; let now = Utc::now().timestamp(); let ticket_lifetime = tools::ticket::TICKET_LIFETIME - 60; if let Some(uinfo) = data[server][username].as_object() { if let Some(timestamp) = uinfo["timestamp"].as_i64() { let age = now - timestamp; if age < ticket_lifetime { let ticket = match uinfo["ticket"].as_str() { Some(t) => t, None => return None, }; let token = match uinfo["token"].as_str() { Some(t) => t, None => return None, }; return Some((ticket.to_owned(), token.to_owned())); } } } None } impl HttpClient { pub fn new(server: &str, username: &str) -> Result { let client = Self::build_client(); let password = if let Some((ticket, _token)) = load_ticket_info(server, username) { ticket } else { Self::get_password(&username)? }; let login = Self::credentials(client.clone(), server.to_owned(), username.to_owned(), password); Ok(Self { client, server: String::from(server), auth: BroadcastFuture::new(login), }) } fn get_password(_username: &str) -> Result { use std::env::VarError::*; match std::env::var("PBS_PASSWORD") { Ok(p) => return Ok(p), Err(NotUnicode(_)) => bail!("PBS_PASSWORD contains bad characters"), Err(NotPresent) => { // Try another method } } // If we're on a TTY, query the user for a password if tty::stdin_isatty() { return Ok(String::from_utf8(tty::read_password("Password: ")?)?); } bail!("no password input mechanism available"); } fn build_client() -> Client> { let mut ssl_connector_builder = SslConnector::builder(SslMethod::tls()).unwrap(); ssl_connector_builder.set_verify(openssl::ssl::SslVerifyMode::NONE); // fixme! let mut httpc = hyper::client::HttpConnector::new(1); httpc.set_nodelay(true); // important for h2 download performance! httpc.set_recv_buffer_size(Some(1024*1024)); //important for h2 download performance! httpc.enforce_http(false); // we want https... let https = hyper_openssl::HttpsConnector::with_connector(httpc, ssl_connector_builder).unwrap(); Client::builder() //.http2_initial_stream_window_size( (1 << 31) - 2) //.http2_initial_connection_window_size( (1 << 31) - 2) .build::<_, Body>(https) } pub fn request(&self, mut req: Request) -> impl Future { let login = self.auth.listen(); let client = self.client.clone(); login.and_then(move |auth| { let enc_ticket = format!("PBSAuthCookie={}", percent_encode(auth.ticket.as_bytes(), DEFAULT_ENCODE_SET)); req.headers_mut().insert("Cookie", HeaderValue::from_str(&enc_ticket).unwrap()); req.headers_mut().insert("CSRFPreventionToken", HeaderValue::from_str(&auth.token).unwrap()); let request = Self::api_request(client, req); request }) } pub fn get(&self, path: &str, data: Option) -> impl Future { let req = Self::request_builder(&self.server, "GET", path, data).unwrap(); self.request(req) } pub fn delete(&mut self, path: &str, data: Option) -> impl Future { let req = Self::request_builder(&self.server, "DELETE", path, data).unwrap(); self.request(req) } pub fn post(&mut self, path: &str, data: Option) -> impl Future { let req = Self::request_builder(&self.server, "POST", path, data).unwrap(); self.request(req) } pub fn download(&mut self, path: &str, output: W) -> impl Future { let mut req = Self::request_builder(&self.server, "GET", path, None).unwrap(); let login = self.auth.listen(); let client = self.client.clone(); login.and_then(move |auth| { let enc_ticket = format!("PBSAuthCookie={}", percent_encode(auth.ticket.as_bytes(), DEFAULT_ENCODE_SET)); req.headers_mut().insert("Cookie", HeaderValue::from_str(&enc_ticket).unwrap()); client.request(req) .map_err(Error::from) .and_then(|resp| { let status = resp.status(); if !status.is_success() { future::Either::A( HttpClient::api_response(resp) .and_then(|_| { bail!("unknown error"); }) ) } else { future::Either::B( resp.into_body() .map_err(Error::from) .fold(output, move |mut acc, chunk| { acc.write_all(&chunk)?; Ok::<_, Error>(acc) }) ) } }) }) } pub fn upload(&mut self, content_type: &str, body: Body, path: &str) -> impl Future { let path = path.trim_matches('/'); let url: Uri = format!("https://{}:8007/{}", &self.server, path).parse().unwrap(); let req = Request::builder() .method("POST") .uri(url) .header("User-Agent", "proxmox-backup-client/1.0") .header("Content-Type", content_type) .body(body).unwrap(); self.request(req) } pub fn start_backup( &self, datastore: &str, backup_type: &str, backup_id: &str, debug: bool, ) -> impl Future, Error=Error> { let param = json!({"backup-type": backup_type, "backup-id": backup_id, "store": datastore, "debug": debug}); let req = Self::request_builder(&self.server, "GET", "/api2/json/backup", Some(param)).unwrap(); self.start_h2_connection(req, String::from(PROXMOX_BACKUP_PROTOCOL_ID_V1!())) .map(|(h2, canceller)| BackupClient::new(h2, canceller)) } pub fn start_backup_reader( &self, datastore: &str, backup_type: &str, backup_id: &str, backup_time: DateTime, debug: bool, ) -> impl Future, Error=Error> { let param = json!({ "backup-type": backup_type, "backup-id": backup_id, "backup-time": backup_time.timestamp(), "store": datastore, "debug": debug, }); let req = Self::request_builder(&self.server, "GET", "/api2/json/reader", Some(param)).unwrap(); self.start_h2_connection(req, String::from(PROXMOX_BACKUP_READER_PROTOCOL_ID_V1!())) .map(|(h2, canceller)| BackupReader::new(h2, canceller)) } pub fn start_h2_connection( &self, mut req: Request, protocol_name: String, ) -> impl Future { let login = self.auth.listen(); let client = self.client.clone(); login.and_then(move |auth| { let enc_ticket = format!("PBSAuthCookie={}", percent_encode(auth.ticket.as_bytes(), DEFAULT_ENCODE_SET)); req.headers_mut().insert("Cookie", HeaderValue::from_str(&enc_ticket).unwrap()); req.headers_mut().insert("UPGRADE", HeaderValue::from_str(&protocol_name).unwrap()); client.request(req) .map_err(Error::from) .and_then(|resp| { let status = resp.status(); if status != http::StatusCode::SWITCHING_PROTOCOLS { future::Either::A(Self::api_response(resp).and_then(|_| { bail!("unknown error"); })) } else { future::Either::B(resp.into_body().on_upgrade().map_err(Error::from)) } }) .and_then(|upgraded| { let max_window_size = (1 << 31) - 2; h2::client::Builder::new() .initial_connection_window_size(max_window_size) .initial_window_size(max_window_size) .max_frame_size(4*1024*1024) .handshake(upgraded) .map_err(Error::from) }) .and_then(|(h2, connection)| { let connection = connection .map_err(|_| panic!("HTTP/2.0 connection failed")); let (connection, canceller) = cancellable(connection)?; // A cancellable future returns an Option which is None when cancelled and // Some when it finished instead, since we don't care about the return type we // need to map it away: let connection = connection.map(|_| ()); // Spawn a new task to drive the connection state hyper::rt::spawn(connection); // Wait until the `SendRequest` handle has available capacity. Ok(h2.ready() .map(move |c| (H2Client::new(c), canceller)) .map_err(Error::from)) }) .flatten() }) } fn credentials( client: Client>, server: String, username: String, password: String, ) -> Box + Send> { let server2 = server.clone(); let create_request = futures::future::lazy(move || { let data = json!({ "username": username, "password": password }); let req = Self::request_builder(&server, "POST", "/api2/json/access/ticket", Some(data)).unwrap(); Self::api_request(client, req) }); let login_future = create_request .and_then(move |cred| { let auth = AuthInfo { username: cred["data"]["username"].as_str().unwrap().to_owned(), ticket: cred["data"]["ticket"].as_str().unwrap().to_owned(), token: cred["data"]["CSRFPreventionToken"].as_str().unwrap().to_owned(), }; let _ = store_ticket_info(&server2, &auth.username, &auth.ticket, &auth.token); Ok(auth) }); Box::new(login_future) } fn api_response(response: Response) -> impl Future { let status = response.status(); response .into_body() .concat2() .map_err(Error::from) .and_then(move |data| { let text = String::from_utf8(data.to_vec()).unwrap(); if status.is_success() { if text.len() > 0 { let value: Value = serde_json::from_str(&text)?; Ok(value) } else { Ok(Value::Null) } } else { bail!("HTTP Error {}: {}", status, text); } }) } fn api_request( client: Client>, req: Request ) -> impl Future { client.request(req) .map_err(Error::from) .and_then(Self::api_response) } pub fn request_builder(server: &str, method: &str, path: &str, data: Option) -> Result, Error> { let path = path.trim_matches('/'); let url: Uri = format!("https://{}:8007/{}", server, path).parse()?; if let Some(data) = data { if method == "POST" { let request = Request::builder() .method(method) .uri(url) .header("User-Agent", "proxmox-backup-client/1.0") .header(hyper::header::CONTENT_TYPE, "application/json") .body(Body::from(data.to_string()))?; return Ok(request); } else { let query = tools::json_object_to_query(data)?; let url: Uri = format!("https://{}:8007/{}?{}", server, path, query).parse()?; let request = Request::builder() .method(method) .uri(url) .header("User-Agent", "proxmox-backup-client/1.0") .header(hyper::header::CONTENT_TYPE, "application/x-www-form-urlencoded") .body(Body::empty())?; return Ok(request); } } let request = Request::builder() .method(method) .uri(url) .header("User-Agent", "proxmox-backup-client/1.0") .header(hyper::header::CONTENT_TYPE, "application/x-www-form-urlencoded") .body(Body::empty())?; Ok(request) } } pub struct BackupReader { h2: H2Client, canceller: Canceller, } impl Drop for BackupReader { fn drop(&mut self) { self.canceller.cancel(); } } impl BackupReader { pub fn new(h2: H2Client, canceller: Canceller) -> Arc { Arc::new(Self { h2, canceller: canceller }) } pub fn get(&self, path: &str, param: Option) -> impl Future { self.h2.get(path, param) } pub fn put(&self, path: &str, param: Option) -> impl Future { self.h2.put(path, param) } pub fn post(&self, path: &str, param: Option) -> impl Future { self.h2.post(path, param) } pub fn download( &self, file_name: &str, output: W, ) -> impl Future { let path = "download"; let param = json!({ "file-name": file_name }); self.h2.download(path, Some(param), output) } pub fn speedtest( &self, output: W, ) -> impl Future { self.h2.download("speedtest", None, output) } pub fn download_chunk( &self, digest: &[u8; 32], output: W, ) -> impl Future { let path = "chunk"; let param = json!({ "digest": proxmox::tools::digest_to_hex(digest) }); self.h2.download(path, Some(param), output) } pub fn force_close(self) { self.canceller.cancel(); } } pub struct BackupClient { h2: H2Client, canceller: Canceller, } impl Drop for BackupClient { fn drop(&mut self) { self.canceller.cancel(); } } impl BackupClient { pub fn new(h2: H2Client, canceller: Canceller) -> Arc { Arc::new(Self { h2, canceller }) } pub fn get(&self, path: &str, param: Option) -> impl Future { self.h2.get(path, param) } pub fn put(&self, path: &str, param: Option) -> impl Future { self.h2.put(path, param) } pub fn post(&self, path: &str, param: Option) -> impl Future { self.h2.post(path, param) } pub fn finish(self: Arc) -> impl Future { self.h2.clone() .post("finish", None) .map(move |_| { self.canceller.cancel(); }) } pub fn force_close(self) { self.canceller.cancel(); } pub fn upload_blob_from_data( &self, data: Vec, file_name: &str, crypt_config: Option>, compress: bool, ) -> impl Future { let h2 = self.h2.clone(); let file_name = file_name.to_owned(); futures::future::ok(()) .and_then(move |_| { let blob = if let Some(ref crypt_config) = crypt_config { DataBlob::encode(&data, Some(crypt_config), compress)? } else { DataBlob::encode(&data, None, compress)? }; let raw_data = blob.into_inner(); Ok(raw_data) }) .and_then(move |raw_data| { let param = json!({"encoded-size": raw_data.len(), "file-name": file_name }); h2.upload("blob", Some(param), raw_data) .map(|_| {}) }) } pub fn upload_blob_from_file>( &self, src_path: P, file_name: &str, crypt_config: Option>, compress: bool, ) -> impl Future { let h2 = self.h2.clone(); let file_name = file_name.to_owned(); let src_path = src_path.as_ref().to_owned(); let task = tokio::fs::File::open(src_path.clone()) .map_err(move |err| format_err!("unable to open file {:?} - {}", src_path, err)) .and_then(move |file| { let contents = vec![]; tokio::io::read_to_end(file, contents) .map_err(Error::from) .and_then(move |(_, contents)| { let blob = if let Some(ref crypt_config) = crypt_config { DataBlob::encode(&contents, Some(crypt_config), compress)? } else { DataBlob::encode(&contents, None, compress)? }; let raw_data = blob.into_inner(); Ok(raw_data) }) .and_then(move |raw_data| { let param = json!({"encoded-size": raw_data.len(), "file-name": file_name }); h2.upload("blob", Some(param), raw_data) .map(|_| {}) }) }); task } pub fn upload_stream( &self, archive_name: &str, stream: impl Stream, prefix: &str, fixed_size: Option, crypt_config: Option>, ) -> impl Future { let known_chunks = Arc::new(Mutex::new(HashSet::new())); let h2 = self.h2.clone(); let h2_2 = self.h2.clone(); let h2_3 = self.h2.clone(); let h2_4 = self.h2.clone(); let mut param = json!({ "archive-name": archive_name }); if let Some(size) = fixed_size { param["size"] = size.into(); } let index_path = format!("{}_index", prefix); let close_path = format!("{}_close", prefix); let prefix = prefix.to_owned(); Self::download_chunk_list(h2, &index_path, archive_name, known_chunks.clone()) .and_then(move |_| { h2_2.post(&index_path, Some(param)) }) .and_then(move |res| { let wid = res.as_u64().unwrap(); Self::upload_chunk_info_stream(h2_3, wid, stream, &prefix, known_chunks.clone(), crypt_config) .and_then(move |(chunk_count, size, _speed)| { let param = json!({ "wid": wid , "chunk-count": chunk_count, "size": size, }); h2_4.post(&close_path, Some(param)) }) .map(|_| ()) }) } fn response_queue() -> ( mpsc::Sender, sync::oneshot::Receiver> ) { let (verify_queue_tx, verify_queue_rx) = mpsc::channel(100); let (verify_result_tx, verify_result_rx) = sync::oneshot::channel(); hyper::rt::spawn( verify_queue_rx .map_err(Error::from) .for_each(|response: h2::client::ResponseFuture| { response .map_err(Error::from) .and_then(H2Client::h2api_response) .and_then(|result| { println!("RESPONSE: {:?}", result); Ok(()) }) .map_err(|err| format_err!("pipelined request failed: {}", err)) }) .then(|result| verify_result_tx.send(result) ) .map_err(|_| { /* ignore closed channel */ }) ); (verify_queue_tx, verify_result_rx) } fn append_chunk_queue(h2: H2Client, wid: u64, path: String) -> ( mpsc::Sender<(MergedChunkInfo, Option)>, sync::oneshot::Receiver> ) { let (verify_queue_tx, verify_queue_rx) = mpsc::channel(64); let (verify_result_tx, verify_result_rx) = sync::oneshot::channel(); let h2_2 = h2.clone(); hyper::rt::spawn( verify_queue_rx .map_err(Error::from) .and_then(move |(merged_chunk_info, response): (MergedChunkInfo, Option)| { match (response, merged_chunk_info) { (Some(response), MergedChunkInfo::Known(list)) => { future::Either::A( response .map_err(Error::from) .and_then(H2Client::h2api_response) .and_then(move |_result| { Ok(MergedChunkInfo::Known(list)) }) ) } (None, MergedChunkInfo::Known(list)) => { future::Either::B(future::ok(MergedChunkInfo::Known(list))) } _ => unreachable!(), } }) .merge_known_chunks() .and_then(move |merged_chunk_info| { match merged_chunk_info { MergedChunkInfo::Known(chunk_list) => { let mut digest_list = vec![]; let mut offset_list = vec![]; for (offset, digest) in chunk_list { //println!("append chunk {} (offset {})", proxmox::tools::digest_to_hex(&digest), offset); digest_list.push(proxmox::tools::digest_to_hex(&digest)); offset_list.push(offset); } println!("append chunks list len ({})", digest_list.len()); let param = json!({ "wid": wid, "digest-list": digest_list, "offset-list": offset_list }); let mut request = H2Client::request_builder("localhost", "PUT", &path, None).unwrap(); request.headers_mut().insert(hyper::header::CONTENT_TYPE, HeaderValue::from_static("application/json")); let param_data = bytes::Bytes::from(param.to_string().as_bytes()); let upload_data = Some(param_data); h2_2.send_request(request, upload_data) .and_then(move |response| { response .map_err(Error::from) .and_then(H2Client::h2api_response) .and_then(|_| Ok(())) }) .map_err(|err| format_err!("pipelined request failed: {}", err)) } _ => unreachable!(), } }) .for_each(|_| Ok(())) .then(|result| verify_result_tx.send(result) ) .map_err(|_| { /* ignore closed channel */ }) ); (verify_queue_tx, verify_result_rx) } fn download_chunk_list( h2: H2Client, path: &str, archive_name: &str, known_chunks: Arc>>, ) -> impl Future { let param = json!({ "archive-name": archive_name }); let request = H2Client::request_builder("localhost", "GET", path, Some(param)).unwrap(); h2.send_request(request, None) .and_then(move |response| { response .map_err(Error::from) .and_then(move |resp| { let status = resp.status(); if !status.is_success() { future::Either::A(H2Client::h2api_response(resp).and_then(|_| { bail!("unknown error"); })) } else { future::Either::B(future::ok(resp.into_body())) } }) .and_then(move |mut body| { let mut release_capacity = body.release_capacity().clone(); DigestListDecoder::new(body.map_err(Error::from)) .for_each(move |chunk| { let _ = release_capacity.release_capacity(chunk.len()); println!("GOT DOWNLOAD {}", proxmox::tools::digest_to_hex(&chunk)); known_chunks.lock().unwrap().insert(chunk); Ok(()) }) }) }) } fn upload_chunk_info_stream( h2: H2Client, wid: u64, stream: impl Stream, prefix: &str, known_chunks: Arc>>, crypt_config: Option>, ) -> impl Future { let repeat = std::sync::Arc::new(AtomicUsize::new(0)); let repeat2 = repeat.clone(); let stream_len = std::sync::Arc::new(AtomicUsize::new(0)); let stream_len2 = stream_len.clone(); let append_chunk_path = format!("{}_index", prefix); let upload_chunk_path = format!("{}_chunk", prefix); let (upload_queue, upload_result) = Self::append_chunk_queue(h2.clone(), wid, append_chunk_path.to_owned()); let start_time = std::time::Instant::now(); stream .and_then(move |data| { let chunk_len = data.len(); repeat.fetch_add(1, Ordering::SeqCst); let offset = stream_len.fetch_add(chunk_len, Ordering::SeqCst) as u64; let mut chunk_builder = DataChunkBuilder::new(data.as_ref()) .compress(true); if let Some(ref crypt_config) = crypt_config { chunk_builder = chunk_builder.crypt_config(crypt_config); } let mut known_chunks = known_chunks.lock().unwrap(); let digest = chunk_builder.digest(); let chunk_is_known = known_chunks.contains(digest); if chunk_is_known { Ok(MergedChunkInfo::Known(vec![(offset, *digest)])) } else { known_chunks.insert(*digest); let chunk = chunk_builder.build()?; Ok(MergedChunkInfo::New(ChunkInfo { chunk, chunk_len: chunk_len as u64, offset })) } }) .merge_known_chunks() .for_each(move |merged_chunk_info| { if let MergedChunkInfo::New(chunk_info) = merged_chunk_info { let offset = chunk_info.offset; let digest = *chunk_info.chunk.digest(); let digest_str = proxmox::tools::digest_to_hex(&digest); let upload_queue = upload_queue.clone(); println!("upload new chunk {} ({} bytes, offset {})", digest_str, chunk_info.chunk_len, offset); let chunk_data = chunk_info.chunk.raw_data(); let param = json!({ "wid": wid, "digest": digest_str, "size": chunk_info.chunk_len, "encoded-size": chunk_data.len(), }); let request = H2Client::request_builder("localhost", "POST", &upload_chunk_path, Some(param)).unwrap(); let upload_data = Some(bytes::Bytes::from(chunk_data)); let new_info = MergedChunkInfo::Known(vec![(offset, digest)]); future::Either::A( h2.send_request(request, upload_data) .and_then(move |response| { upload_queue.clone().send((new_info, Some(response))) .map(|_| ()).map_err(Error::from) }) ) } else { future::Either::B( upload_queue.clone().send((merged_chunk_info, None)) .map(|_| ()).map_err(Error::from) ) } }) .then(move |result| { //println!("RESULT {:?}", result); upload_result.map_err(Error::from).and_then(|upload1_result| { Ok(upload1_result.and(result)) }) }) .flatten() .and_then(move |_| { let repeat = repeat2.load(Ordering::SeqCst); let stream_len = stream_len2.load(Ordering::SeqCst); let speed = ((stream_len*1000000)/(1024*1024))/(start_time.elapsed().as_micros() as usize); println!("Uploaded {} chunks in {} seconds ({} MB/s).", repeat, start_time.elapsed().as_secs(), speed); if repeat > 0 { println!("Average chunk size was {} bytes.", stream_len/repeat); println!("Time per request: {} microseconds.", (start_time.elapsed().as_micros())/(repeat as u128)); } Ok((repeat, stream_len, speed)) }) } pub fn upload_speedtest(&self) -> impl Future { let mut data = vec![]; // generate pseudo random byte sequence for i in 0..1024*1024 { for j in 0..4 { let byte = ((i >> (j<<3))&0xff) as u8; data.push(byte); } } let item_len = data.len(); let repeat = std::sync::Arc::new(AtomicUsize::new(0)); let repeat2 = repeat.clone(); let (upload_queue, upload_result) = Self::response_queue(); let start_time = std::time::Instant::now(); let h2 = self.h2.clone(); futures::stream::repeat(data) .take_while(move |_| { repeat.fetch_add(1, Ordering::SeqCst); Ok(start_time.elapsed().as_secs() < 5) }) .for_each(move |data| { let h2 = h2.clone(); let upload_queue = upload_queue.clone(); println!("send test data ({} bytes)", data.len()); let request = H2Client::request_builder("localhost", "POST", "speedtest", None).unwrap(); h2.send_request(request, Some(bytes::Bytes::from(data))) .and_then(move |response| { upload_queue.send(response) .map(|_| ()).map_err(Error::from) }) }) .then(move |result| { println!("RESULT {:?}", result); upload_result.map_err(Error::from).and_then(|upload1_result| { Ok(upload1_result.and(result)) }) }) .flatten() .and_then(move |_| { let repeat = repeat2.load(Ordering::SeqCst); println!("Uploaded {} chunks in {} seconds.", repeat, start_time.elapsed().as_secs()); let speed = ((item_len*1000000*(repeat as usize))/(1024*1024))/(start_time.elapsed().as_micros() as usize); if repeat > 0 { println!("Time per request: {} microseconds.", (start_time.elapsed().as_micros())/(repeat as u128)); } Ok(speed) }) } } #[derive(Clone)] pub struct H2Client { h2: h2::client::SendRequest, } impl H2Client { pub fn new(h2: h2::client::SendRequest) -> Self { Self { h2 } } pub fn get(&self, path: &str, param: Option) -> impl Future { let req = Self::request_builder("localhost", "GET", path, param).unwrap(); self.request(req) } pub fn put(&self, path: &str, param: Option) -> impl Future { let req = Self::request_builder("localhost", "PUT", path, param).unwrap(); self.request(req) } pub fn post(&self, path: &str, param: Option) -> impl Future { let req = Self::request_builder("localhost", "POST", path, param).unwrap(); self.request(req) } pub fn download(&self, path: &str, param: Option, output: W) -> impl Future { let request = Self::request_builder("localhost", "GET", path, param).unwrap(); self.send_request(request, None) .and_then(move |response| { response .map_err(Error::from) .and_then(move |resp| { let status = resp.status(); if !status.is_success() { future::Either::A( H2Client::h2api_response(resp) .and_then(|_| { bail!("unknown error"); }) ) } else { let mut body = resp.into_body(); let mut release_capacity = body.release_capacity().clone(); future::Either::B( body .map_err(Error::from) .fold(output, move |mut acc, chunk| { let _ = release_capacity.release_capacity(chunk.len()); acc.write_all(&chunk)?; Ok::<_, Error>(acc) }) ) } }) }) } pub fn upload(&self, path: &str, param: Option, data: Vec) -> impl Future { let request = Self::request_builder("localhost", "POST", path, param).unwrap(); self.h2.clone() .ready() .map_err(Error::from) .and_then(move |mut send_request| { let (response, stream) = send_request.send_request(request, false).unwrap(); PipeToSendStream::new(bytes::Bytes::from(data), stream) .and_then(|_| { response .map_err(Error::from) .and_then(Self::h2api_response) }) }) } fn request( &self, request: Request<()>, ) -> impl Future { self.send_request(request, None) .and_then(move |response| { response .map_err(Error::from) .and_then(Self::h2api_response) }) } fn send_request( &self, request: Request<()>, data: Option, ) -> impl Future { self.h2.clone() .ready() .map_err(Error::from) .and_then(move |mut send_request| { if let Some(data) = data { let (response, stream) = send_request.send_request(request, false).unwrap(); future::Either::A(PipeToSendStream::new(data, stream) .and_then(move |_| { future::ok(response) })) } else { let (response, _stream) = send_request.send_request(request, true).unwrap(); future::Either::B(future::ok(response)) } }) } fn h2api_response(response: Response) -> impl Future { let status = response.status(); let (_head, mut body) = response.into_parts(); // The `release_capacity` handle allows the caller to manage // flow control. // // Whenever data is received, the caller is responsible for // releasing capacity back to the server once it has freed // the data from memory. let mut release_capacity = body.release_capacity().clone(); body .map(move |chunk| { // Let the server send more data. let _ = release_capacity.release_capacity(chunk.len()); chunk }) .concat2() .map_err(Error::from) .and_then(move |data| { let text = String::from_utf8(data.to_vec()).unwrap(); if status.is_success() { if text.len() > 0 { let mut value: Value = serde_json::from_str(&text)?; if let Some(map) = value.as_object_mut() { if let Some(data) = map.remove("data") { return Ok(data); } } bail!("got result without data property"); } else { Ok(Value::Null) } } else { bail!("HTTP Error {}: {}", status, text); } }) } // Note: We always encode parameters with the url pub fn request_builder(server: &str, method: &str, path: &str, data: Option) -> Result, Error> { let path = path.trim_matches('/'); if let Some(data) = data { let query = tools::json_object_to_query(data)?; // We detected problem with hyper around 6000 characters - seo we try to keep on the safe side if query.len() > 4096 { bail!("h2 query data too large ({} bytes) - please encode data inside body", query.len()); } let url: Uri = format!("https://{}:8007/{}?{}", server, path, query).parse()?; let request = Request::builder() .method(method) .uri(url) .header("User-Agent", "proxmox-backup-client/1.0") .header(hyper::header::CONTENT_TYPE, "application/x-www-form-urlencoded") .body(())?; return Ok(request); } else { let url: Uri = format!("https://{}:8007/{}", server, path).parse()?; let request = Request::builder() .method(method) .uri(url) .header("User-Agent", "proxmox-backup-client/1.0") .header(hyper::header::CONTENT_TYPE, "application/x-www-form-urlencoded") .body(())?; Ok(request) } } }