Simple WebSockets notification about new request (#1202)
* Splitting methods requiring signing into separate trait * Single place where RPC apis are created. * Separating eth_filter * Separating eth_signing * Stubs for Personal Signer methods * Test for EthSigningQueueClient * TransactionConfirmation API * Exposing PersonalSigner API * Defining ApiSets dependent on context * Removing types * Supporting sending notification to WS connected SystemUIs * Sending a notification on every new messages * Adding logs to signing queue * Shutting down broadcaster * Refactoring the signing queue * Fixing wait loop in case of spurious wake-ups.
This commit is contained in:
		
							parent
							
								
									35753f22f7
								
							
						
					
					
						commit
						18dac64abb
					
				| @ -51,7 +51,7 @@ fn do_start(conf: Configuration, deps: Dependencies) -> SignerServer { | |||||||
| 	}); | 	}); | ||||||
| 
 | 
 | ||||||
| 	let start_result = { | 	let start_result = { | ||||||
| 		let server = signer::ServerBuilder::new(); | 		let server = signer::ServerBuilder::new(deps.apis.signer_queue.clone()); | ||||||
| 		let server = rpc_apis::setup_rpc(server, deps.apis, rpc_apis::ApiSet::SafeContext); | 		let server = rpc_apis::setup_rpc(server, deps.apis, rpc_apis::ApiSet::SafeContext); | ||||||
| 		server.start(addr) | 		server.start(addr) | ||||||
| 	}; | 	}; | ||||||
|  | |||||||
| @ -14,78 +14,281 @@ | |||||||
| // You should have received a copy of the GNU General Public License
 | // You should have received a copy of the GNU General Public License
 | ||||||
| // along with Parity.  If not, see <http://www.gnu.org/licenses/>.
 | // along with Parity.  If not, see <http://www.gnu.org/licenses/>.
 | ||||||
| 
 | 
 | ||||||
| use std::sync::Mutex; | use std::thread; | ||||||
|  | use std::time::{Instant, Duration}; | ||||||
|  | use std::sync::{mpsc, Mutex, RwLock, Arc}; | ||||||
| use std::collections::HashMap; | use std::collections::HashMap; | ||||||
| use v1::types::{TransactionRequest, TransactionConfirmation}; | use v1::types::{TransactionRequest, TransactionConfirmation}; | ||||||
| use util::U256; | use util::{U256, H256}; | ||||||
|  | 
 | ||||||
|  | 
 | ||||||
|  | /// Possible events happening in the queue that can be listened to.
 | ||||||
|  | #[derive(Debug, PartialEq)] | ||||||
|  | pub enum QueueEvent { | ||||||
|  | 	/// Receiver should stop work upon receiving `Finish` message.
 | ||||||
|  | 	Finish, | ||||||
|  | 	/// Informs about new request.
 | ||||||
|  | 	NewRequest(U256), | ||||||
|  | 	/// Request rejected.
 | ||||||
|  | 	RequestRejected(U256), | ||||||
|  | 	/// Request resolved.
 | ||||||
|  | 	RequestConfirmed(U256), | ||||||
|  | } | ||||||
|  | 
 | ||||||
|  | /// Defines possible errors returned from queue receiving method.
 | ||||||
|  | #[derive(Debug, PartialEq)] | ||||||
|  | pub enum QueueError { | ||||||
|  | 	/// Returned when method has been already used (no receiver available).
 | ||||||
|  | 	AlreadyUsed, | ||||||
|  | 	/// Returned when receiver encounters an error.
 | ||||||
|  | 	ReceiverError(mpsc::RecvError), | ||||||
|  | } | ||||||
|  | 
 | ||||||
|  | /// Message Receiver type
 | ||||||
|  | pub type QueueEventReceiver = mpsc::Receiver<QueueEvent>; | ||||||
| 
 | 
 | ||||||
| /// A queue of transactions awaiting to be confirmed and signed.
 | /// A queue of transactions awaiting to be confirmed and signed.
 | ||||||
| pub trait SigningQueue: Send + Sync { | pub trait SigningQueue: Send + Sync { | ||||||
| 	/// Add new request to the queue.
 | 	/// Add new request to the queue.
 | ||||||
| 	fn add_request(&self, transaction: TransactionRequest) -> U256; | 	/// Returns a `ConfirmationPromise` that can be used to await for resolution of given request.
 | ||||||
|  | 	fn add_request(&self, transaction: TransactionRequest) -> ConfirmationPromise; | ||||||
| 
 | 
 | ||||||
| 	/// Remove request from the queue.
 | 	/// Removes a request from the queue.
 | ||||||
| 	fn remove_request(&self, id: U256) -> Option<TransactionConfirmation>; | 	/// Notifies possible token holders that transaction was rejected.
 | ||||||
|  | 	fn request_rejected(&self, id: U256) -> Option<TransactionConfirmation>; | ||||||
|  | 
 | ||||||
|  | 	/// Removes a request from the queue.
 | ||||||
|  | 	/// Notifies possible token holders that transaction was confirmed and given hash was assigned.
 | ||||||
|  | 	fn request_confirmed(&self, id: U256, hash: H256) -> Option<TransactionConfirmation>; | ||||||
|  | 
 | ||||||
|  | 	/// Returns a request if it is contained in the queue.
 | ||||||
|  | 	fn peek(&self, id: &U256) -> Option<TransactionConfirmation>; | ||||||
| 
 | 
 | ||||||
| 	/// Return copy of all the requests in the queue.
 | 	/// Return copy of all the requests in the queue.
 | ||||||
| 	fn requests(&self) -> Vec<TransactionConfirmation>; | 	fn requests(&self) -> Vec<TransactionConfirmation>; | ||||||
| } | } | ||||||
| 
 | 
 | ||||||
|  | #[derive(Debug, PartialEq)] | ||||||
|  | enum ConfirmationResult { | ||||||
|  | 	/// The transaction has not yet been confirmed nor rejected.
 | ||||||
|  | 	Waiting, | ||||||
|  | 	/// The transaction has been rejected.
 | ||||||
|  | 	Rejected, | ||||||
|  | 	/// The transaction has been confirmed.
 | ||||||
|  | 	Confirmed(H256), | ||||||
|  | } | ||||||
|  | 
 | ||||||
|  | /// Time you need to confirm the transaction in UI.
 | ||||||
|  | /// This is the amount of time token holder will wait before
 | ||||||
|  | /// returning `None`.
 | ||||||
|  | /// Unless we have a multi-threaded RPC this will lock
 | ||||||
|  | /// any other incoming call!
 | ||||||
|  | const QUEUE_TIMEOUT_DURATION_SEC : u64 = 20; | ||||||
|  | 
 | ||||||
|  | /// A handle to submitted request.
 | ||||||
|  | /// Allows to block and wait for a resolution of that request.
 | ||||||
|  | pub struct ConfirmationToken { | ||||||
|  | 	result: Arc<Mutex<ConfirmationResult>>, | ||||||
|  | 	handle: thread::Thread, | ||||||
|  | 	request: TransactionConfirmation, | ||||||
|  | } | ||||||
|  | 
 | ||||||
|  | pub struct ConfirmationPromise { | ||||||
|  | 	id: U256, | ||||||
|  | 	result: Arc<Mutex<ConfirmationResult>>, | ||||||
|  | } | ||||||
|  | 
 | ||||||
|  | impl ConfirmationToken { | ||||||
|  | 	/// Submit solution to all listeners
 | ||||||
|  | 	fn resolve(&self, result: Option<H256>) { | ||||||
|  | 		let mut res = self.result.lock().unwrap(); | ||||||
|  | 		*res = result.map_or(ConfirmationResult::Rejected, |h| ConfirmationResult::Confirmed(h)); | ||||||
|  | 		// Notify listener
 | ||||||
|  | 		self.handle.unpark(); | ||||||
|  | 	} | ||||||
|  | 
 | ||||||
|  | 	fn as_promise(&self) -> ConfirmationPromise { | ||||||
|  | 		ConfirmationPromise { | ||||||
|  | 			id: self.request.id, | ||||||
|  | 			result: self.result.clone(), | ||||||
|  | 		} | ||||||
|  | 	} | ||||||
|  | } | ||||||
|  | 
 | ||||||
|  | impl ConfirmationPromise { | ||||||
|  | 	/// Blocks current thread and awaits for
 | ||||||
|  | 	/// resolution of the transaction (rejected / confirmed)
 | ||||||
|  | 	/// Returns `None` if transaction was rejected or timeout reached.
 | ||||||
|  | 	/// Returns `Some(hash)` if transaction was confirmed.
 | ||||||
|  | 	pub fn wait_with_timeout(&self) -> Option<H256> { | ||||||
|  | 		let timeout = Duration::from_secs(QUEUE_TIMEOUT_DURATION_SEC); | ||||||
|  | 		let deadline = Instant::now() + timeout; | ||||||
|  | 
 | ||||||
|  | 		info!(target: "own_tx", "Signer: Awaiting transaction confirmation... ({:?}).", self.id); | ||||||
|  | 		loop { | ||||||
|  | 			let now = Instant::now(); | ||||||
|  | 			if now >= deadline { | ||||||
|  | 				break; | ||||||
|  | 			} | ||||||
|  | 			// Park thread (may wake up spuriously)
 | ||||||
|  | 			thread::park_timeout(deadline - now); | ||||||
|  | 			// Take confirmation result
 | ||||||
|  | 			let res = self.result.lock().unwrap(); | ||||||
|  | 			// Check the result
 | ||||||
|  | 			match *res { | ||||||
|  | 				ConfirmationResult::Rejected => return None, | ||||||
|  | 				ConfirmationResult::Confirmed(h) => return Some(h), | ||||||
|  | 				ConfirmationResult::Waiting => continue, | ||||||
|  | 			} | ||||||
|  | 		} | ||||||
|  | 		// We reached the timeout. Just return `None`
 | ||||||
|  | 		trace!(target: "own_tx", "Signer: Confirmation timeout reached... ({:?}).", self.id); | ||||||
|  | 		None | ||||||
|  | 	} | ||||||
|  | } | ||||||
|  | 
 | ||||||
| /// Queue for all unconfirmed transactions.
 | /// Queue for all unconfirmed transactions.
 | ||||||
| pub struct ConfirmationsQueue { | pub struct ConfirmationsQueue { | ||||||
| 	id: Mutex<U256>, | 	id: Mutex<U256>, | ||||||
| 	queue: Mutex<HashMap<U256, TransactionConfirmation>>, | 	queue: RwLock<HashMap<U256, ConfirmationToken>>, | ||||||
|  | 	sender: Mutex<mpsc::Sender<QueueEvent>>, | ||||||
|  | 	receiver: Mutex<Option<mpsc::Receiver<QueueEvent>>>, | ||||||
| } | } | ||||||
| 
 | 
 | ||||||
| impl Default for ConfirmationsQueue { | impl Default for ConfirmationsQueue { | ||||||
| 	fn default() -> Self { | 	fn default() -> Self { | ||||||
|  | 		let (send, recv) = mpsc::channel(); | ||||||
|  | 
 | ||||||
| 		ConfirmationsQueue { | 		ConfirmationsQueue { | ||||||
| 			id: Mutex::new(U256::from(0)), | 			id: Mutex::new(U256::from(0)), | ||||||
| 			queue: Mutex::new(HashMap::new()), | 			queue: RwLock::new(HashMap::new()), | ||||||
|  | 			sender: Mutex::new(send), | ||||||
|  | 			receiver: Mutex::new(Some(recv)), | ||||||
| 		} | 		} | ||||||
| 	} | 	} | ||||||
| } | } | ||||||
| 
 | 
 | ||||||
|  | impl ConfirmationsQueue { | ||||||
|  | 	/// Blocks the thread and starts listening for notifications regarding all actions in the queue.
 | ||||||
|  | 	/// For each event, `listener` callback will be invoked.
 | ||||||
|  | 	/// This method can be used only once (only single consumer of events can exist).
 | ||||||
|  | 	pub fn start_listening<F>(&self, listener: F) -> Result<(), QueueError> | ||||||
|  | 		where F: Fn(QueueEvent) -> () { | ||||||
|  | 		let recv = self.receiver.lock().unwrap().take(); | ||||||
|  | 		if let None = recv { | ||||||
|  | 			return Err(QueueError::AlreadyUsed); | ||||||
|  | 		} | ||||||
|  | 		let recv = recv.expect("Check for none is done earlier."); | ||||||
|  | 
 | ||||||
|  | 		loop { | ||||||
|  | 			let message = try!(recv.recv().map_err(|e| QueueError::ReceiverError(e))); | ||||||
|  | 			if let QueueEvent::Finish = message { | ||||||
|  | 				return Ok(()); | ||||||
|  | 			} | ||||||
|  | 
 | ||||||
|  | 			listener(message); | ||||||
|  | 		} | ||||||
|  | 	} | ||||||
|  | 
 | ||||||
|  | 	/// Notifies consumer that the communcation is over.
 | ||||||
|  | 	/// No more events will be sent after this function is invoked.
 | ||||||
|  | 	pub fn finish(&self) { | ||||||
|  | 		self.notify(QueueEvent::Finish); | ||||||
|  | 	} | ||||||
|  | 
 | ||||||
|  | 	/// Notifies receiver about the event happening in this queue.
 | ||||||
|  | 	fn notify(&self, message: QueueEvent) { | ||||||
|  | 		// We don't really care about the result
 | ||||||
|  | 		let _ = self.sender.lock().unwrap().send(message); | ||||||
|  | 	} | ||||||
|  | 
 | ||||||
|  | 	/// Removes transaction from this queue and notifies `ConfirmationPromise` holders about the result.
 | ||||||
|  | 	/// Notifies also a receiver about that event.
 | ||||||
|  | 	fn remove(&self, id: U256, result: Option<H256>) -> Option<TransactionConfirmation> { | ||||||
|  | 		let token = self.queue.write().unwrap().remove(&id); | ||||||
|  | 
 | ||||||
|  | 		if let Some(token) = token { | ||||||
|  | 			// notify receiver about the event
 | ||||||
|  | 			self.notify(result.map_or_else( | ||||||
|  | 				|| QueueEvent::RequestRejected(id), | ||||||
|  | 				|_| QueueEvent::RequestConfirmed(id) | ||||||
|  | 			)); | ||||||
|  | 			// notify token holders about resolution
 | ||||||
|  | 			token.resolve(result); | ||||||
|  | 			// return a result
 | ||||||
|  | 			return Some(token.request.clone()); | ||||||
|  | 		} | ||||||
|  | 		None | ||||||
|  | 	} | ||||||
|  | } | ||||||
|  | 
 | ||||||
|  | impl Drop for ConfirmationsQueue { | ||||||
|  | 	fn drop(&mut self) { | ||||||
|  | 		self.finish(); | ||||||
|  | 	} | ||||||
|  | } | ||||||
|  | 
 | ||||||
| impl SigningQueue for  ConfirmationsQueue { | impl SigningQueue for  ConfirmationsQueue { | ||||||
| 	fn add_request(&self, transaction: TransactionRequest) -> U256 { | 	fn add_request(&self, transaction: TransactionRequest) -> ConfirmationPromise { | ||||||
| 		// Increment id
 | 		// Increment id
 | ||||||
| 		let id = { | 		let id = { | ||||||
| 			let mut last_id = self.id.lock().unwrap(); | 			let mut last_id = self.id.lock().unwrap(); | ||||||
| 			*last_id = *last_id + U256::from(1); | 			*last_id = *last_id + U256::from(1); | ||||||
| 			*last_id | 			*last_id | ||||||
| 		}; | 		}; | ||||||
| 		let mut queue = self.queue.lock().unwrap(); | 		// Add request to queue
 | ||||||
| 		queue.insert(id, TransactionConfirmation { | 		let res = { | ||||||
|  | 			let mut queue = self.queue.write().unwrap(); | ||||||
|  | 			queue.insert(id, ConfirmationToken { | ||||||
|  | 				result: Arc::new(Mutex::new(ConfirmationResult::Waiting)), | ||||||
|  | 				handle: thread::current(), | ||||||
|  | 				request: TransactionConfirmation { | ||||||
| 					id: id, | 					id: id, | ||||||
| 					transaction: transaction, | 					transaction: transaction, | ||||||
|  | 				}, | ||||||
| 			}); | 			}); | ||||||
| 		id | 			debug!(target: "own_tx", "Signer: New transaction ({:?}) in confirmation queue.", id); | ||||||
|  | 			queue.get(&id).map(|token| token.as_promise()).expect("Token was just inserted.") | ||||||
|  | 		}; | ||||||
|  | 		// Notify listeners
 | ||||||
|  | 		self.notify(QueueEvent::NewRequest(id)); | ||||||
|  | 		res | ||||||
|  | 
 | ||||||
| 	} | 	} | ||||||
| 
 | 
 | ||||||
| 	fn remove_request(&self, id: U256) -> Option<TransactionConfirmation> { | 	fn peek(&self, id: &U256) -> Option<TransactionConfirmation> { | ||||||
| 		self.queue.lock().unwrap().remove(&id) | 		self.queue.read().unwrap().get(id).map(|token| token.request.clone()) | ||||||
|  | 	} | ||||||
|  | 
 | ||||||
|  | 	fn request_rejected(&self, id: U256) -> Option<TransactionConfirmation> { | ||||||
|  | 		debug!(target: "own_tx", "Signer: Transaction rejected ({:?}).", id); | ||||||
|  | 		self.remove(id, None) | ||||||
|  | 	} | ||||||
|  | 
 | ||||||
|  | 	fn request_confirmed(&self, id: U256, hash: H256) -> Option<TransactionConfirmation> { | ||||||
|  | 		debug!(target: "own_tx", "Signer: Transaction confirmed ({:?}).", id); | ||||||
|  | 		self.remove(id, Some(hash)) | ||||||
| 	} | 	} | ||||||
| 
 | 
 | ||||||
| 	fn requests(&self) -> Vec<TransactionConfirmation> { | 	fn requests(&self) -> Vec<TransactionConfirmation> { | ||||||
| 		let queue = self.queue.lock().unwrap(); | 		let queue = self.queue.read().unwrap(); | ||||||
| 		queue.values().cloned().collect() | 		queue.values().map(|token| token.request.clone()).collect() | ||||||
| 	} | 	} | ||||||
| } | } | ||||||
| 
 | 
 | ||||||
| 
 | 
 | ||||||
| #[cfg(test)] | #[cfg(test)] | ||||||
| mod test { | mod test { | ||||||
|  | 	use std::time::Duration; | ||||||
|  | 	use std::thread; | ||||||
|  | 	use std::sync::{Arc, Mutex}; | ||||||
| 	use util::hash::Address; | 	use util::hash::Address; | ||||||
| 	use util::numbers::U256; | 	use util::numbers::{U256, H256}; | ||||||
| 	use v1::types::TransactionRequest; | 	use v1::types::TransactionRequest; | ||||||
| 	use super::*; | 	use super::*; | ||||||
| 
 | 
 | ||||||
| 	#[test] | 	fn request() -> TransactionRequest { | ||||||
| 	fn should_work_for_hashset() { | 		TransactionRequest { | ||||||
| 		// given
 |  | ||||||
| 		let queue = ConfirmationsQueue::default(); |  | ||||||
| 
 |  | ||||||
| 		let request = TransactionRequest { |  | ||||||
| 			from: Address::from(1), | 			from: Address::from(1), | ||||||
| 			to: Some(Address::from(2)), | 			to: Some(Address::from(2)), | ||||||
| 			gas_price: None, | 			gas_price: None, | ||||||
| @ -93,7 +296,63 @@ mod test { | |||||||
| 			value: Some(U256::from(10_000_000)), | 			value: Some(U256::from(10_000_000)), | ||||||
| 			data: None, | 			data: None, | ||||||
| 			nonce: None, | 			nonce: None, | ||||||
| 		}; | 		} | ||||||
|  | 	} | ||||||
|  | 
 | ||||||
|  | 	#[test] | ||||||
|  | 	fn should_wait_for_hash() { | ||||||
|  | 		// given
 | ||||||
|  | 		let queue = Arc::new(ConfirmationsQueue::default()); | ||||||
|  | 		let request = request(); | ||||||
|  | 
 | ||||||
|  | 		// when
 | ||||||
|  | 		let q = queue.clone(); | ||||||
|  | 		let handle = thread::spawn(move || { | ||||||
|  | 			let v = q.add_request(request); | ||||||
|  | 			v.wait_with_timeout().expect("Should return hash") | ||||||
|  | 		}); | ||||||
|  | 
 | ||||||
|  | 		let id = U256::from(1); | ||||||
|  | 		while queue.peek(&id).is_none() { | ||||||
|  | 			// Just wait for the other thread to start
 | ||||||
|  | 			thread::sleep(Duration::from_millis(100)); | ||||||
|  | 		} | ||||||
|  | 		queue.request_confirmed(id, H256::from(1)); | ||||||
|  | 
 | ||||||
|  | 		// then
 | ||||||
|  | 		assert_eq!(handle.join().expect("Thread should finish nicely"), H256::from(1)); | ||||||
|  | 	} | ||||||
|  | 
 | ||||||
|  | 	#[test] | ||||||
|  | 	fn should_receive_notification() { | ||||||
|  | 		// given
 | ||||||
|  | 		let received = Arc::new(Mutex::new(None)); | ||||||
|  | 		let queue = Arc::new(ConfirmationsQueue::default()); | ||||||
|  | 		let request = request(); | ||||||
|  | 
 | ||||||
|  | 		// when
 | ||||||
|  | 		let q = queue.clone(); | ||||||
|  | 		let r = received.clone(); | ||||||
|  | 		let handle = thread::spawn(move || { | ||||||
|  | 			q.start_listening(move |notification| { | ||||||
|  | 				let mut v = r.lock().unwrap(); | ||||||
|  | 				*v = Some(notification); | ||||||
|  | 			}).expect("Should be closed nicely.") | ||||||
|  | 		}); | ||||||
|  | 		queue.add_request(request); | ||||||
|  | 		queue.finish(); | ||||||
|  | 
 | ||||||
|  | 		// then
 | ||||||
|  | 		handle.join().expect("Thread should finish nicely"); | ||||||
|  | 		let r = received.lock().unwrap().take(); | ||||||
|  | 		assert_eq!(r, Some(QueueEvent::NewRequest(U256::from(1)))); | ||||||
|  | 	} | ||||||
|  | 
 | ||||||
|  | 	#[test] | ||||||
|  | 	fn should_add_transactions() { | ||||||
|  | 		// given
 | ||||||
|  | 		let queue = ConfirmationsQueue::default(); | ||||||
|  | 		let request = request(); | ||||||
| 
 | 
 | ||||||
| 		// when
 | 		// when
 | ||||||
| 		queue.add_request(request.clone()); | 		queue.add_request(request.clone()); | ||||||
|  | |||||||
| @ -499,7 +499,7 @@ impl<C, S, A, M, EM> Eth for EthClient<C, S, A, M, EM> where | |||||||
| 			.and_then(|(raw_transaction, )| { | 			.and_then(|(raw_transaction, )| { | ||||||
| 				let raw_transaction = raw_transaction.to_vec(); | 				let raw_transaction = raw_transaction.to_vec(); | ||||||
| 				match UntrustedRlp::new(&raw_transaction).as_val() { | 				match UntrustedRlp::new(&raw_transaction).as_val() { | ||||||
| 					Ok(signed_transaction) => dispatch_transaction(&*take_weak!(self.client), &*take_weak!(self.miner), signed_transaction), | 					Ok(signed_transaction) => to_value(&dispatch_transaction(&*take_weak!(self.client), &*take_weak!(self.miner), signed_transaction)), | ||||||
| 					Err(_) => to_value(&H256::zero()), | 					Err(_) => to_value(&H256::zero()), | ||||||
| 				} | 				} | ||||||
| 		}) | 		}) | ||||||
|  | |||||||
| @ -53,9 +53,9 @@ impl EthSigning for EthSigningQueueClient  { | |||||||
| 		from_params::<(TransactionRequest, )>(params) | 		from_params::<(TransactionRequest, )>(params) | ||||||
| 			.and_then(|(request, )| { | 			.and_then(|(request, )| { | ||||||
| 				let queue = take_weak!(self.queue); | 				let queue = take_weak!(self.queue); | ||||||
| 				queue.add_request(request); | 				let id = queue.add_request(request); | ||||||
| 				// TODO [ToDr] Block and wait for confirmation?
 | 				let result = id.wait_with_timeout(); | ||||||
| 				to_value(&H256::zero()) | 				to_value(&result.unwrap_or_else(H256::new)) | ||||||
| 		}) | 		}) | ||||||
| 	} | 	} | ||||||
| } | } | ||||||
| @ -102,7 +102,7 @@ impl<C, A, M> EthSigning for EthSigningUnsafeClient<C, A, M> where | |||||||
| 			.and_then(|(request, )| { | 			.and_then(|(request, )| { | ||||||
| 				let accounts = take_weak!(self.accounts); | 				let accounts = take_weak!(self.accounts); | ||||||
| 				match accounts.account_secret(&request.from) { | 				match accounts.account_secret(&request.from) { | ||||||
| 					Ok(secret) => sign_and_dispatch(&self.client, &self.miner, request, secret), | 					Ok(secret) => to_value(&sign_and_dispatch(&*take_weak!(self.client), &*take_weak!(self.miner), request, secret)), | ||||||
| 					Err(_) => to_value(&H256::zero()) | 					Err(_) => to_value(&H256::zero()) | ||||||
| 				} | 				} | ||||||
| 		}) | 		}) | ||||||
|  | |||||||
| @ -52,16 +52,14 @@ pub use self::traces::TracesClient; | |||||||
| pub use self::rpc::RpcClient; | pub use self::rpc::RpcClient; | ||||||
| 
 | 
 | ||||||
| use v1::types::TransactionRequest; | use v1::types::TransactionRequest; | ||||||
| use std::sync::Weak; |  | ||||||
| use ethcore::miner::{AccountDetails, MinerService}; | use ethcore::miner::{AccountDetails, MinerService}; | ||||||
| use ethcore::client::MiningBlockChainClient; | use ethcore::client::MiningBlockChainClient; | ||||||
| use ethcore::transaction::{Action, SignedTransaction, Transaction}; | use ethcore::transaction::{Action, SignedTransaction, Transaction}; | ||||||
| use util::numbers::*; | use util::numbers::*; | ||||||
| use util::rlp::encode; | use util::rlp::encode; | ||||||
| use util::bytes::ToPretty; | use util::bytes::ToPretty; | ||||||
| use jsonrpc_core::{Error, to_value, Value}; |  | ||||||
| 
 | 
 | ||||||
| fn dispatch_transaction<C, M>(client: &C, miner: &M, signed_transaction: SignedTransaction) -> Result<Value, Error> | fn dispatch_transaction<C, M>(client: &C, miner: &M, signed_transaction: SignedTransaction) -> H256 | ||||||
| 	where C: MiningBlockChainClient, M: MinerService { | 	where C: MiningBlockChainClient, M: MinerService { | ||||||
| 	let hash = signed_transaction.hash(); | 	let hash = signed_transaction.hash(); | ||||||
| 
 | 
 | ||||||
| @ -72,13 +70,11 @@ fn dispatch_transaction<C, M>(client: &C, miner: &M, signed_transaction: SignedT | |||||||
| 		} | 		} | ||||||
| 	}); | 	}); | ||||||
| 
 | 
 | ||||||
| 	to_value(&import.map(|_| hash).unwrap_or(H256::zero())) | 	import.map(|_| hash).unwrap_or(H256::zero()) | ||||||
| } | } | ||||||
| 
 | 
 | ||||||
| fn sign_and_dispatch<C, M>(client: &Weak<C>, miner: &Weak<M>, request: TransactionRequest, secret: H256) -> Result<Value, Error> | fn sign_and_dispatch<C, M>(client: &C, miner: &M, request: TransactionRequest, secret: H256) -> H256 | ||||||
| 	where C: MiningBlockChainClient, M: MinerService { | 	where C: MiningBlockChainClient, M: MinerService { | ||||||
| 	let client = take_weak!(client); |  | ||||||
| 	let miner = take_weak!(miner); |  | ||||||
| 
 | 
 | ||||||
| 	let signed_transaction = { | 	let signed_transaction = { | ||||||
| 		Transaction { | 		Transaction { | ||||||
|  | |||||||
| @ -83,7 +83,7 @@ impl<A: 'static, C: 'static, M: 'static> Personal for PersonalClient<A, C, M> | |||||||
| 			.and_then(|(request, password)| { | 			.and_then(|(request, password)| { | ||||||
| 				let accounts = take_weak!(self.accounts); | 				let accounts = take_weak!(self.accounts); | ||||||
| 				match accounts.locked_account_secret(&request.from, &password) { | 				match accounts.locked_account_secret(&request.from, &password) { | ||||||
| 					Ok(secret) => sign_and_dispatch(&self.client, &self.miner, request, secret), | 					Ok(secret) => to_value(&sign_and_dispatch(&*take_weak!(self.client), &*take_weak!(self.miner), request, secret)), | ||||||
| 					Err(_) => to_value(&H256::zero()), | 					Err(_) => to_value(&H256::zero()), | ||||||
| 				} | 				} | ||||||
| 		}) | 		}) | ||||||
|  | |||||||
| @ -63,19 +63,27 @@ impl<A: 'static, C: 'static, M: 'static> PersonalSigner for SignerClient<A, C, M | |||||||
| 			|(id, modification, pass)| { | 			|(id, modification, pass)| { | ||||||
| 				let accounts = take_weak!(self.accounts); | 				let accounts = take_weak!(self.accounts); | ||||||
| 				let queue = take_weak!(self.queue); | 				let queue = take_weak!(self.queue); | ||||||
| 				queue.remove_request(id) | 				let client = take_weak!(self.client); | ||||||
| 					.and_then(|confirmation| { | 				let miner = take_weak!(self.miner); | ||||||
|  | 				queue.peek(&id).and_then(|confirmation| { | ||||||
| 						let mut request = confirmation.transaction; | 						let mut request = confirmation.transaction; | ||||||
| 						// apply modification
 | 						// apply modification
 | ||||||
| 						if let Some(gas_price) = modification.gas_price { | 						if let Some(gas_price) = modification.gas_price { | ||||||
| 							request.gas_price = Some(gas_price); | 							request.gas_price = Some(gas_price); | ||||||
| 						} | 						} | ||||||
| 						match accounts.locked_account_secret(&request.from, &pass) { | 						match accounts.locked_account_secret(&request.from, &pass) { | ||||||
| 							Ok(secret) => Some(sign_and_dispatch(&self.client, &self.miner, request, secret)), | 							Ok(secret) => { | ||||||
|  | 								let hash = sign_and_dispatch(&*client, &*miner, request, secret); | ||||||
|  | 								queue.request_confirmed(id, hash); | ||||||
|  | 								Some(to_value(&hash)) | ||||||
|  | 							}, | ||||||
| 							Err(_) => None | 							Err(_) => None | ||||||
| 						} | 						} | ||||||
| 					}) | 					}) | ||||||
| 					.unwrap_or_else(|| to_value(&H256::zero())) | 					.unwrap_or_else(|| { | ||||||
|  | 						queue.request_rejected(id); | ||||||
|  | 						to_value(&H256::zero()) | ||||||
|  | 					}) | ||||||
| 			} | 			} | ||||||
| 		) | 		) | ||||||
| 	} | 	} | ||||||
| @ -84,7 +92,7 @@ impl<A: 'static, C: 'static, M: 'static> PersonalSigner for SignerClient<A, C, M | |||||||
| 		from_params::<(U256, )>(params).and_then( | 		from_params::<(U256, )>(params).and_then( | ||||||
| 			|(id, )| { | 			|(id, )| { | ||||||
| 				let queue = take_weak!(self.queue); | 				let queue = take_weak!(self.queue); | ||||||
| 				let res = queue.remove_request(id); | 				let res = queue.request_rejected(id); | ||||||
| 				to_value(&res.is_some()) | 				to_value(&res.is_some()) | ||||||
| 			} | 			} | ||||||
| 		) | 		) | ||||||
|  | |||||||
| @ -30,12 +30,15 @@ | |||||||
| //!
 | //!
 | ||||||
| //! ```
 | //! ```
 | ||||||
| //! extern crate ethcore_signer;
 | //! extern crate ethcore_signer;
 | ||||||
|  | //! extern crate ethcore_rpc;
 | ||||||
| //!
 | //!
 | ||||||
|  | //! use std::sync::Arc;
 | ||||||
| //! use ethcore_signer::ServerBuilder;
 | //! use ethcore_signer::ServerBuilder;
 | ||||||
|  | //! use ethcore_rpc::ConfirmationsQueue;
 | ||||||
| //!
 | //!
 | ||||||
| //!	fn main() {
 | //!	fn main() {
 | ||||||
| //!	 let builder = ServerBuilder::new();
 | //!	 let queue = Arc::new(ConfirmationsQueue::default());
 | ||||||
| //!	 let _server = builder.start("127.0.0.1:8084".parse().unwrap()).unwrap();
 | //!	 let _server = ServerBuilder::new(queue).start("127.0.0.1:8084".parse().unwrap());
 | ||||||
| //!	}
 | //!	}
 | ||||||
| //! ```
 | //! ```
 | ||||||
| 
 | 
 | ||||||
|  | |||||||
| @ -25,7 +25,7 @@ use std::sync::Arc; | |||||||
| use std::net::SocketAddr; | use std::net::SocketAddr; | ||||||
| use util::panics::{PanicHandler, OnPanicListener, MayPanic}; | use util::panics::{PanicHandler, OnPanicListener, MayPanic}; | ||||||
| use jsonrpc_core::{IoHandler, IoDelegate}; | use jsonrpc_core::{IoHandler, IoDelegate}; | ||||||
| use rpc::Extendable; | use rpc::{Extendable, ConfirmationsQueue}; | ||||||
| 
 | 
 | ||||||
| mod session; | mod session; | ||||||
| 
 | 
 | ||||||
| @ -49,15 +49,10 @@ impl From<ws::Error> for ServerError { | |||||||
| 
 | 
 | ||||||
| /// Builder for `WebSockets` server
 | /// Builder for `WebSockets` server
 | ||||||
| pub struct ServerBuilder { | pub struct ServerBuilder { | ||||||
|  | 	queue: Arc<ConfirmationsQueue>, | ||||||
| 	handler: Arc<IoHandler>, | 	handler: Arc<IoHandler>, | ||||||
| } | } | ||||||
| 
 | 
 | ||||||
| impl Default for ServerBuilder { |  | ||||||
| 	fn default() -> Self { |  | ||||||
| 		ServerBuilder::new() |  | ||||||
| 	} |  | ||||||
| } |  | ||||||
| 
 |  | ||||||
| impl Extendable for ServerBuilder { | impl Extendable for ServerBuilder { | ||||||
| 	fn add_delegate<D: Send + Sync + 'static>(&self, delegate: IoDelegate<D>) { | 	fn add_delegate<D: Send + Sync + 'static>(&self, delegate: IoDelegate<D>) { | ||||||
| 		self.handler.add_delegate(delegate); | 		self.handler.add_delegate(delegate); | ||||||
| @ -66,30 +61,32 @@ impl Extendable for ServerBuilder { | |||||||
| 
 | 
 | ||||||
| impl ServerBuilder { | impl ServerBuilder { | ||||||
| 	/// Creates new `ServerBuilder`
 | 	/// Creates new `ServerBuilder`
 | ||||||
| 	pub fn new() -> Self { | 	pub fn new(queue: Arc<ConfirmationsQueue>) -> Self { | ||||||
| 		ServerBuilder { | 		ServerBuilder { | ||||||
| 			handler: Arc::new(IoHandler::new()) | 			queue: queue, | ||||||
|  | 			handler: Arc::new(IoHandler::new()), | ||||||
| 		} | 		} | ||||||
| 	} | 	} | ||||||
| 
 | 
 | ||||||
| 	/// Starts a new `WebSocket` server in separate thread.
 | 	/// Starts a new `WebSocket` server in separate thread.
 | ||||||
| 	/// Returns a `Server` handle which closes the server when droped.
 | 	/// Returns a `Server` handle which closes the server when droped.
 | ||||||
| 	pub fn start(self, addr: SocketAddr) -> Result<Server, ServerError> { | 	pub fn start(self, addr: SocketAddr) -> Result<Server, ServerError> { | ||||||
| 		Server::start(addr, self.handler) | 		Server::start(addr, self.handler, self.queue) | ||||||
| 	} | 	} | ||||||
| } | } | ||||||
| 
 | 
 | ||||||
| /// `WebSockets` server implementation.
 | /// `WebSockets` server implementation.
 | ||||||
| pub struct Server { | pub struct Server { | ||||||
| 	handle: Option<thread::JoinHandle<ws::WebSocket<session::Factory>>>, | 	handle: Option<thread::JoinHandle<ws::WebSocket<session::Factory>>>, | ||||||
| 	broadcaster: ws::Sender, | 	broadcaster_handle: Option<thread::JoinHandle<()>>, | ||||||
|  | 	queue: Arc<ConfirmationsQueue>, | ||||||
| 	panic_handler: Arc<PanicHandler>, | 	panic_handler: Arc<PanicHandler>, | ||||||
| } | } | ||||||
| 
 | 
 | ||||||
| impl Server { | impl Server { | ||||||
| 	/// Starts a new `WebSocket` server in separate thread.
 | 	/// Starts a new `WebSocket` server in separate thread.
 | ||||||
| 	/// Returns a `Server` handle which closes the server when droped.
 | 	/// Returns a `Server` handle which closes the server when droped.
 | ||||||
| 	pub fn start(addr: SocketAddr, handler: Arc<IoHandler>) -> Result<Server, ServerError> { | 	fn start(addr: SocketAddr, handler: Arc<IoHandler>, queue: Arc<ConfirmationsQueue>) -> Result<Server, ServerError> { | ||||||
| 		let config = { | 		let config = { | ||||||
| 			let mut config = ws::Settings::default(); | 			let mut config = ws::Settings::default(); | ||||||
| 			config.max_connections = 5; | 			config.max_connections = 5; | ||||||
| @ -103,6 +100,7 @@ impl Server { | |||||||
| 		let panic_handler = PanicHandler::new_in_arc(); | 		let panic_handler = PanicHandler::new_in_arc(); | ||||||
| 		let ph = panic_handler.clone(); | 		let ph = panic_handler.clone(); | ||||||
| 		let broadcaster = ws.broadcaster(); | 		let broadcaster = ws.broadcaster(); | ||||||
|  | 
 | ||||||
| 		// Spawn a thread with event loop
 | 		// Spawn a thread with event loop
 | ||||||
| 		let handle = thread::spawn(move || { | 		let handle = thread::spawn(move || { | ||||||
| 			ph.catch_panic(move || { | 			ph.catch_panic(move || { | ||||||
| @ -110,10 +108,24 @@ impl Server { | |||||||
| 			}).unwrap() | 			}).unwrap() | ||||||
| 		}); | 		}); | ||||||
| 
 | 
 | ||||||
|  | 		// Spawn a thread for broadcasting
 | ||||||
|  | 		let ph = panic_handler.clone(); | ||||||
|  | 		let q = queue.clone(); | ||||||
|  | 		let broadcaster_handle = thread::spawn(move || { | ||||||
|  | 			ph.catch_panic(move || { | ||||||
|  | 				q.start_listening(|_message| { | ||||||
|  | 					// TODO [ToDr] Some better structure here for messages.
 | ||||||
|  | 					broadcaster.send("new_message").unwrap(); | ||||||
|  | 				}).expect("It's the only place we are running start_listening. It shouldn't fail."); | ||||||
|  | 				broadcaster.shutdown().expect("Broadcaster should close gently.") | ||||||
|  | 			}).unwrap() | ||||||
|  | 		}); | ||||||
|  | 
 | ||||||
| 		// Return a handle
 | 		// Return a handle
 | ||||||
| 		Ok(Server { | 		Ok(Server { | ||||||
| 			handle: Some(handle), | 			handle: Some(handle), | ||||||
| 			broadcaster: broadcaster, | 			broadcaster_handle: Some(broadcaster_handle), | ||||||
|  | 			queue: queue, | ||||||
| 			panic_handler: panic_handler, | 			panic_handler: panic_handler, | ||||||
| 		}) | 		}) | ||||||
| 	} | 	} | ||||||
| @ -127,7 +139,8 @@ impl MayPanic for Server { | |||||||
| 
 | 
 | ||||||
| impl Drop for Server { | impl Drop for Server { | ||||||
| 	fn drop(&mut self) { | 	fn drop(&mut self) { | ||||||
| 		self.broadcaster.shutdown().expect("WsServer should close nicely."); | 		self.queue.finish(); | ||||||
|  | 		self.broadcaster_handle.take().unwrap().join().unwrap(); | ||||||
| 		self.handle.take().unwrap().join().unwrap(); | 		self.handle.take().unwrap().join().unwrap(); | ||||||
| 	} | 	} | ||||||
| } | } | ||||||
|  | |||||||
		Loading…
	
		Reference in New Issue
	
	Block a user