Skip to content

Commit

Permalink
Merge pull request #1238 from TheBlueMatt/2022-01-lockorder-checks
Browse files Browse the repository at this point in the history
Fix and test lockorder
  • Loading branch information
TheBlueMatt authored Jan 14, 2022
2 parents 89cbb6d + 8f007c7 commit 34cdca9
Show file tree
Hide file tree
Showing 8 changed files with 244 additions and 17 deletions.
4 changes: 4 additions & 0 deletions .github/workflows/build.yml
Original file line number Diff line number Diff line change
Expand Up @@ -101,6 +101,10 @@ jobs:
RUSTFLAGS="-C link-dead-code" cargo build --verbose --color always --features rpc-client
RUSTFLAGS="-C link-dead-code" cargo build --verbose --color always --features rpc-client,rest-client
RUSTFLAGS="-C link-dead-code" cargo build --verbose --color always --features rpc-client,rest-client,tokio
- name: Test backtrace-debug builds on Rust ${{ matrix.toolchain }}
if: "matrix.build-no-std"
run: |
cd lightning && cargo test --verbose --color always --features backtrace
- name: Test on Rust ${{ matrix.toolchain }} with net-tokio
if: "matrix.build-net-tokio && !matrix.coverage"
run: cargo test --verbose --color always
Expand Down
1 change: 1 addition & 0 deletions lightning/Cargo.toml
Original file line number Diff line number Diff line change
Expand Up @@ -39,6 +39,7 @@ secp256k1 = { version = "0.20.2", default-features = false, features = ["alloc"]
hashbrown = { version = "0.11", optional = true }
hex = { version = "0.3", optional = true }
regex = { version = "0.1.80", optional = true }
backtrace = { version = "0.3", optional = true }

core2 = { version = "0.3.0", optional = true, default-features = false }

Expand Down
5 changes: 3 additions & 2 deletions lightning/src/chain/chainmonitor.rs
Original file line number Diff line number Diff line change
Expand Up @@ -920,9 +920,10 @@ mod tests {
merkle_root: Default::default() };
nodes[0].chain_monitor.chain_monitor.best_block_updated(&latest_header, nodes[0].best_block_info().1 + LATENCY_GRACE_PERIOD_BLOCKS);
} else {
for (funding_outpoint, update_ids) in chanmon_cfgs[0].persister.chain_sync_monitor_persistences.lock().unwrap().iter() {
let persistences = chanmon_cfgs[0].persister.chain_sync_monitor_persistences.lock().unwrap().clone();
for (funding_outpoint, update_ids) in persistences {
for update_id in update_ids {
nodes[0].chain_monitor.chain_monitor.channel_monitor_updated(*funding_outpoint, *update_id).unwrap();
nodes[0].chain_monitor.chain_monitor.channel_monitor_updated(funding_outpoint, update_id).unwrap();
}
}
}
Expand Down
213 changes: 213 additions & 0 deletions lightning/src/debug_sync.rs
Original file line number Diff line number Diff line change
@@ -0,0 +1,213 @@
pub use ::alloc::sync::Arc;
use core::ops::{Deref, DerefMut};
use core::time::Duration;

use std::collections::HashSet;
use std::cell::RefCell;

use std::sync::atomic::{AtomicUsize, Ordering};

use std::sync::Mutex as StdMutex;
use std::sync::MutexGuard as StdMutexGuard;
use std::sync::RwLock as StdRwLock;
use std::sync::RwLockReadGuard as StdRwLockReadGuard;
use std::sync::RwLockWriteGuard as StdRwLockWriteGuard;
use std::sync::Condvar as StdCondvar;

#[cfg(feature = "backtrace")]
use backtrace::Backtrace;

pub type LockResult<Guard> = Result<Guard, ()>;

pub struct Condvar {
inner: StdCondvar,
}

impl Condvar {
pub fn new() -> Condvar {
Condvar { inner: StdCondvar::new() }
}

pub fn wait<'a, T>(&'a self, guard: MutexGuard<'a, T>) -> LockResult<MutexGuard<'a, T>> {
let mutex: &'a Mutex<T> = guard.mutex;
self.inner.wait(guard.into_inner()).map(|lock| MutexGuard { mutex, lock }).map_err(|_| ())
}

#[allow(unused)]
pub fn wait_timeout<'a, T>(&'a self, guard: MutexGuard<'a, T>, dur: Duration) -> LockResult<(MutexGuard<'a, T>, ())> {
let mutex = guard.mutex;
self.inner.wait_timeout(guard.into_inner(), dur).map(|(lock, _)| (MutexGuard { mutex, lock }, ())).map_err(|_| ())
}

pub fn notify_all(&self) { self.inner.notify_all(); }
}

thread_local! {
/// We track the set of locks currently held by a reference to their `MutexMetadata`
static MUTEXES_HELD: RefCell<HashSet<Arc<MutexMetadata>>> = RefCell::new(HashSet::new());
}
static MUTEX_IDX: AtomicUsize = AtomicUsize::new(0);

/// Metadata about a single mutex, by id, the set of things locked-before it, and the backtrace of
/// when the Mutex itself was constructed.
struct MutexMetadata {
mutex_idx: u64,
locked_before: StdMutex<HashSet<Arc<MutexMetadata>>>,
#[cfg(feature = "backtrace")]
mutex_construction_bt: Backtrace,
}
impl PartialEq for MutexMetadata {
fn eq(&self, o: &MutexMetadata) -> bool { self.mutex_idx == o.mutex_idx }
}
impl Eq for MutexMetadata {}
impl std::hash::Hash for MutexMetadata {
fn hash<H: std::hash::Hasher>(&self, hasher: &mut H) { hasher.write_u64(self.mutex_idx); }
}

pub struct Mutex<T: Sized> {
inner: StdMutex<T>,
deps: Arc<MutexMetadata>,
}

#[must_use = "if unused the Mutex will immediately unlock"]
pub struct MutexGuard<'a, T: Sized + 'a> {
mutex: &'a Mutex<T>,
lock: StdMutexGuard<'a, T>,
}

impl<'a, T: Sized> MutexGuard<'a, T> {
fn into_inner(self) -> StdMutexGuard<'a, T> {
// Somewhat unclear why we cannot move out of self.lock, but doing so gets E0509.
unsafe {
let v: StdMutexGuard<'a, T> = std::ptr::read(&self.lock);
std::mem::forget(self);
v
}
}
}

impl<T: Sized> Drop for MutexGuard<'_, T> {
fn drop(&mut self) {
MUTEXES_HELD.with(|held| {
held.borrow_mut().remove(&self.mutex.deps);
});
}
}

impl<T: Sized> Deref for MutexGuard<'_, T> {
type Target = T;

fn deref(&self) -> &T {
&self.lock.deref()
}
}

impl<T: Sized> DerefMut for MutexGuard<'_, T> {
fn deref_mut(&mut self) -> &mut T {
self.lock.deref_mut()
}
}

impl<T> Mutex<T> {
pub fn new(inner: T) -> Mutex<T> {
Mutex {
inner: StdMutex::new(inner),
deps: Arc::new(MutexMetadata {
locked_before: StdMutex::new(HashSet::new()),
mutex_idx: MUTEX_IDX.fetch_add(1, Ordering::Relaxed) as u64,
#[cfg(feature = "backtrace")]
mutex_construction_bt: Backtrace::new(),
}),
}
}

pub fn lock<'a>(&'a self) -> LockResult<MutexGuard<'a, T>> {
MUTEXES_HELD.with(|held| {
// For each mutex which is currently locked, check that no mutex's locked-before
// set includes the mutex we're about to lock, which would imply a lockorder
// inversion.
for locked in held.borrow().iter() {
for locked_dep in locked.locked_before.lock().unwrap().iter() {
if *locked_dep == self.deps {
#[cfg(feature = "backtrace")]
panic!("Tried to violate existing lockorder.\nMutex that should be locked after the current lock was created at the following backtrace.\nNote that to get a backtrace for the lockorder violation, you should set RUST_BACKTRACE=1\n{:?}", locked.mutex_construction_bt);
#[cfg(not(feature = "backtrace"))]
panic!("Tried to violate existing lockorder. Build with the backtrace feature for more info.");
}
}
// Insert any already-held mutexes in our locked-before set.
self.deps.locked_before.lock().unwrap().insert(Arc::clone(locked));
}
held.borrow_mut().insert(Arc::clone(&self.deps));
});
self.inner.lock().map(|lock| MutexGuard { mutex: self, lock }).map_err(|_| ())
}

pub fn try_lock<'a>(&'a self) -> LockResult<MutexGuard<'a, T>> {
let res = self.inner.try_lock().map(|lock| MutexGuard { mutex: self, lock }).map_err(|_| ());
if res.is_ok() {
MUTEXES_HELD.with(|held| {
// Since a try-lock will simply fail if the lock is held already, we do not
// consider try-locks to ever generate lockorder inversions. However, if a try-lock
// succeeds, we do consider it to have created lockorder dependencies.
for locked in held.borrow().iter() {
self.deps.locked_before.lock().unwrap().insert(Arc::clone(locked));
}
held.borrow_mut().insert(Arc::clone(&self.deps));
});
}
res
}
}

pub struct RwLock<T: ?Sized> {
inner: StdRwLock<T>
}

pub struct RwLockReadGuard<'a, T: ?Sized + 'a> {
lock: StdRwLockReadGuard<'a, T>,
}

pub struct RwLockWriteGuard<'a, T: ?Sized + 'a> {
lock: StdRwLockWriteGuard<'a, T>,
}

impl<T: ?Sized> Deref for RwLockReadGuard<'_, T> {
type Target = T;

fn deref(&self) -> &T {
&self.lock.deref()
}
}

impl<T: ?Sized> Deref for RwLockWriteGuard<'_, T> {
type Target = T;

fn deref(&self) -> &T {
&self.lock.deref()
}
}

impl<T: ?Sized> DerefMut for RwLockWriteGuard<'_, T> {
fn deref_mut(&mut self) -> &mut T {
self.lock.deref_mut()
}
}

impl<T> RwLock<T> {
pub fn new(inner: T) -> RwLock<T> {
RwLock { inner: StdRwLock::new(inner) }
}

pub fn read<'a>(&'a self) -> LockResult<RwLockReadGuard<'a, T>> {
self.inner.read().map(|lock| RwLockReadGuard { lock }).map_err(|_| ())
}

pub fn write<'a>(&'a self) -> LockResult<RwLockWriteGuard<'a, T>> {
self.inner.write().map(|lock| RwLockWriteGuard { lock }).map_err(|_| ())
}

pub fn try_write<'a>(&'a self) -> LockResult<RwLockWriteGuard<'a, T>> {
self.inner.try_write().map(|lock| RwLockWriteGuard { lock }).map_err(|_| ())
}
}
8 changes: 8 additions & 0 deletions lightning/src/lib.rs
Original file line number Diff line number Diff line change
Expand Up @@ -143,8 +143,16 @@ mod prelude {
pub use alloc::string::ToString;
}

#[cfg(all(feature = "std", test))]
mod debug_sync;
#[cfg(all(feature = "backtrace", feature = "std", test))]
extern crate backtrace;

#[cfg(feature = "std")]
mod sync {
#[cfg(test)]
pub use debug_sync::*;
#[cfg(not(test))]
pub use ::std::sync::{Arc, Mutex, Condvar, MutexGuard, RwLock, RwLockReadGuard};
}

Expand Down
8 changes: 4 additions & 4 deletions lightning/src/ln/channelmanager.rs
Original file line number Diff line number Diff line change
Expand Up @@ -3931,12 +3931,12 @@ impl<Signer: Sign, M: Deref, T: Deref, K: Deref, F: Deref, L: Deref> ChannelMana
}

fn finalize_claims(&self, mut sources: Vec<HTLCSource>) {
let mut outbounds = self.pending_outbound_payments.lock().unwrap();
let mut pending_events = self.pending_events.lock().unwrap();
for source in sources.drain(..) {
if let HTLCSource::OutboundRoute { session_priv, payment_id, path, .. } = source {
let mut session_priv_bytes = [0; 32];
session_priv_bytes.copy_from_slice(&session_priv[..]);
let mut outbounds = self.pending_outbound_payments.lock().unwrap();
if let hash_map::Entry::Occupied(mut payment) = outbounds.entry(payment_id) {
assert!(payment.get().is_fulfilled());
if payment.get_mut().remove(&session_priv_bytes, None) {
Expand Down Expand Up @@ -5321,8 +5321,8 @@ where
inbound_payment.expiry_time > header.time as u64
});

let mut pending_events = self.pending_events.lock().unwrap();
let mut outbounds = self.pending_outbound_payments.lock().unwrap();
let mut pending_events = self.pending_events.lock().unwrap();
outbounds.retain(|payment_id, payment| {
if payment.remaining_parts() != 0 { return true }
if let PendingOutboundPayment::Retryable { starting_block_height, payment_hash, .. } = payment {
Expand Down Expand Up @@ -6151,6 +6151,8 @@ impl<Signer: Sign, M: Deref, T: Deref, K: Deref, F: Deref, L: Deref> Writeable f
peer_state.latest_features.write(writer)?;
}

let pending_inbound_payments = self.pending_inbound_payments.lock().unwrap();
let pending_outbound_payments = self.pending_outbound_payments.lock().unwrap();
let events = self.pending_events.lock().unwrap();
(events.len() as u64).write(writer)?;
for event in events.iter() {
Expand All @@ -6172,14 +6174,12 @@ impl<Signer: Sign, M: Deref, T: Deref, K: Deref, F: Deref, L: Deref> Writeable f
(self.last_node_announcement_serial.load(Ordering::Acquire) as u32).write(writer)?;
(self.highest_seen_timestamp.load(Ordering::Acquire) as u32).write(writer)?;

let pending_inbound_payments = self.pending_inbound_payments.lock().unwrap();
(pending_inbound_payments.len() as u64).write(writer)?;
for (hash, pending_payment) in pending_inbound_payments.iter() {
hash.write(writer)?;
pending_payment.write(writer)?;
}

let pending_outbound_payments = self.pending_outbound_payments.lock().unwrap();
// For backwards compat, write the session privs and their total length.
let mut num_pending_outbounds_compat: u64 = 0;
for (_, outbound) in pending_outbound_payments.iter() {
Expand Down
Loading

0 comments on commit 34cdca9

Please sign in to comment.