run: |
cd lightning
RUSTFLAGS="--cfg=require_route_graph_test" cargo test
- RUSTFLAGS="--cfg=require_route_graph_test" cargo test --features hashbrown,ahash
+ RUSTFLAGS="--cfg=require_route_graph_test" cargo test --features hashbrown
cd ..
- name: Run benchmarks on Rust ${{ matrix.toolchain }}
run: |
harness = false
[features]
-hashbrown = ["lightning/hashbrown", "lightning/ahash"]
+hashbrown = ["lightning/hashbrown"]
[dependencies]
lightning = { path = "../lightning", features = ["_test_utils", "criterion"] }
pass
elif feature == "no-std":
pass
- elif feature == "ahash":
+ elif feature == "possiblyrandom":
pass
elif feature == "getrandom":
pass
lightning-rapid-gossip-sync = { path = "../lightning-rapid-gossip-sync" }
bitcoin = { version = "0.30.2", features = ["secp-lowmemory"] }
hex = { package = "hex-conservative", version = "0.1.1", default-features = false }
-hashbrown = "0.13"
afl = { version = "0.12", optional = true }
honggfuzz = { version = "0.5", optional = true, default-features = false }
use lightning::onion_message::messenger::{Destination, MessageRouter, OnionMessagePath};
use lightning::util::test_channel_signer::{TestChannelSigner, EnforcementState};
use lightning::util::errors::APIError;
+use lightning::util::hash_tables::*;
use lightning::util::logger::Logger;
use lightning::util::config::UserConfig;
use lightning::util::ser::{Readable, ReadableArgs, Writeable, Writer};
use std::mem;
use std::cmp::{self, Ordering};
-use hashbrown::{HashSet, hash_map, HashMap};
use std::sync::{Arc,Mutex};
use std::sync::atomic;
use std::io::Cursor;
logger,
keys,
persister,
- latest_monitors: Mutex::new(HashMap::new()),
+ latest_monitors: Mutex::new(new_hash_map()),
}
}
}
fn update_channel(&self, funding_txo: OutPoint, update: &channelmonitor::ChannelMonitorUpdate) -> chain::ChannelMonitorUpdateStatus {
let mut map_lock = self.latest_monitors.lock().unwrap();
- let mut map_entry = match map_lock.entry(funding_txo) {
- hash_map::Entry::Occupied(entry) => entry,
- hash_map::Entry::Vacant(_) => panic!("Didn't have monitor on update call"),
- };
+ let map_entry = map_lock.get_mut(&funding_txo).expect("Didn't have monitor on update call");
let deserialized_monitor = <(BlockHash, channelmonitor::ChannelMonitor<TestChannelSigner>)>::
- read(&mut Cursor::new(&map_entry.get().1), (&*self.keys, &*self.keys)).unwrap().1;
+ read(&mut Cursor::new(&map_entry.1), (&*self.keys, &*self.keys)).unwrap().1;
deserialized_monitor.update_monitor(update, &&TestBroadcaster{}, &&FuzzEstimator { ret_val: atomic::AtomicU32::new(253) }, &self.logger).unwrap();
let mut ser = VecWriter(Vec::new());
deserialized_monitor.write(&mut ser).unwrap();
- map_entry.insert((update.update_id, ser.0));
+ *map_entry = (update.update_id, ser.0);
self.chain_monitor.update_channel(funding_txo, update)
}
($node_id: expr, $fee_estimator: expr) => { {
let logger: Arc<dyn Logger> = Arc::new(test_logger::TestLogger::new($node_id.to_string(), out.clone()));
let node_secret = SecretKey::from_slice(&[0, 0, 0, 0, 0, 0, 0, 0, 0, 0, 0, 0, 0, 0, 0, 0, 0, 0, 0, 0, 0, 0, 0, 0, 0, 0, 0, 0, 0, 0, 1, $node_id]).unwrap();
- let keys_manager = Arc::new(KeyProvider { node_secret, rand_bytes_id: atomic::AtomicU32::new(0), enforcement_states: Mutex::new(HashMap::new()) });
+ let keys_manager = Arc::new(KeyProvider { node_secret, rand_bytes_id: atomic::AtomicU32::new(0), enforcement_states: Mutex::new(new_hash_map()) });
let monitor = Arc::new(TestChainMonitor::new(broadcast.clone(), logger.clone(), $fee_estimator.clone(),
Arc::new(TestPersister {
update_ret: Mutex::new(ChannelMonitorUpdateStatus::Completed)
config.manually_accept_inbound_channels = true;
}
- let mut monitors = HashMap::new();
+ let mut monitors = new_hash_map();
let mut old_monitors = $old_monitors.latest_monitors.lock().unwrap();
for (outpoint, (update_id, monitor_ser)) in old_monitors.drain() {
monitors.insert(outpoint, <(BlockHash, ChannelMonitor<TestChannelSigner>)>::read(&mut Cursor::new(&monitor_ser), (&*$keys_manager, &*$keys_manager)).expect("Failed to read monitor").1);
chain_monitor.latest_monitors.lock().unwrap().insert(outpoint, (update_id, monitor_ser));
}
- let mut monitor_refs = HashMap::new();
+ let mut monitor_refs = new_hash_map();
for (outpoint, monitor) in monitors.iter_mut() {
monitor_refs.insert(*outpoint, monitor);
}
// In case we get 256 payments we may have a hash collision, resulting in the
// second claim/fail call not finding the duplicate-hash HTLC, so we have to
// deduplicate the calls here.
- let mut claim_set = HashSet::new();
+ let mut claim_set = new_hash_map();
let mut events = nodes[$node].get_and_clear_pending_events();
// Sort events so that PendingHTLCsForwardable get processed last. This avoids a
// case where we first process a PendingHTLCsForwardable, then claim/fail on a
for event in events.drain(..) {
match event {
events::Event::PaymentClaimable { payment_hash, .. } => {
- if claim_set.insert(payment_hash.0) {
+ if claim_set.insert(payment_hash.0, ()).is_none() {
if $fail {
nodes[$node].fail_htlc_backwards(&payment_hash);
} else {
use lightning::routing::utxo::UtxoLookup;
use lightning::routing::router::{InFlightHtlcs, PaymentParameters, Route, RouteParameters, Router};
use lightning::util::config::{ChannelConfig, UserConfig};
+use lightning::util::hash_tables::*;
use lightning::util::errors::APIError;
use lightning::util::test_channel_signer::{TestChannelSigner, EnforcementState};
use lightning::util::logger::Logger;
use bitcoin::secp256k1::schnorr;
use std::cell::RefCell;
-use hashbrown::{HashMap, hash_map};
use std::convert::TryInto;
use std::cmp;
use std::sync::{Arc, Mutex};
peers,
funding_txn: Vec::new(),
- txids_confirmed: HashMap::new(),
+ txids_confirmed: new_hash_map(),
header_hashes: vec![(genesis_block(Network::Bitcoin).block_hash(), 0)],
height: 0,
max_height: 0,
let mut txdata = Vec::with_capacity(all_txn.len());
for (idx, tx) in all_txn.iter().enumerate() {
let txid = tx.txid();
- match self.txids_confirmed.entry(txid) {
- hash_map::Entry::Vacant(e) => {
- e.insert(self.height);
- txdata.push((idx + 1, tx));
- },
- _ => {},
- }
+ self.txids_confirmed.entry(txid).or_insert_with(|| {
+ txdata.push((idx + 1, tx));
+ self.height
+ });
}
self.blocks_connected += 1;
node_secret: our_network_key.clone(),
inbound_payment_key: KeyMaterial(inbound_payment_key.try_into().unwrap()),
counter: AtomicU64::new(0),
- signer_state: RefCell::new(HashMap::new())
+ signer_state: RefCell::new(new_hash_map())
});
let network = Network::Bitcoin;
let best_block_timestamp = genesis_block(network).header.time;
let mut intercepted_htlcs: Vec<InterceptId> = Vec::new();
let mut payments_sent: u16 = 0;
let mut pending_funding_generation: Vec<(ChannelId, PublicKey, u64, ScriptBuf)> = Vec::new();
- let mut pending_funding_signatures = HashMap::new();
+ let mut pending_funding_signatures = new_hash_map();
loop {
match get_slice!(1)[0] {
use lightning::util::indexed_map::{IndexedMap, self};
use std::collections::{BTreeMap, btree_map};
-use hashbrown::HashSet;
+use lightning::util::hash_tables::*;
use crate::utils::test_logger;
}
}
- let mut key_set = HashSet::with_capacity(256);
+ let mut key_set = hash_map_with_capacity(1024);
for k in indexed.unordered_keys() {
- assert!(key_set.insert(*k));
+ assert!(key_set.insert(*k, ()).is_none());
assert!(btree.contains_key(k));
}
assert_eq!(key_set.len(), btree.len());
key_set.clear();
for (k, v) in indexed.unordered_iter() {
- assert!(key_set.insert(*k));
+ assert!(key_set.insert(*k, ()).is_none());
assert_eq!(btree.get(k).unwrap(), v);
}
assert_eq!(key_set.len(), btree.len());
key_set.clear();
for (k, v) in indexed_clone.unordered_iter_mut() {
- assert!(key_set.insert(*k));
+ assert!(key_set.insert(*k, ()).is_none());
assert_eq!(btree.get(k).unwrap(), v);
}
assert_eq!(key_set.len(), btree.len());
use lightning::routing::router::{find_route, PaymentParameters, RouteHint, RouteHintHop, RouteParameters};
use lightning::routing::scoring::{ProbabilisticScorer, ProbabilisticScoringFeeParameters, ProbabilisticScoringDecayParameters};
use lightning::util::config::UserConfig;
+use lightning::util::hash_tables::*;
use lightning::util::ser::Readable;
use bitcoin::hashes::Hash;
use crate::utils::test_logger;
use std::convert::TryInto;
-use hashbrown::HashSet;
use std::sync::Arc;
use std::sync::atomic::{AtomicUsize, Ordering};
net_graph: &net_graph,
};
- let mut node_pks = HashSet::new();
+ let mut node_pks = new_hash_map();
let mut scid = 42;
macro_rules! first_hops {
count => {
for _ in 0..count {
scid += 1;
- let rnid = node_pks.iter().skip(u16::from_be_bytes(get_slice!(2).try_into().unwrap()) as usize % node_pks.len()).next().unwrap();
+ let (rnid, _) =
+ node_pks.iter().skip(u16::from_be_bytes(get_slice!(2).try_into().unwrap()) as usize % node_pks.len()).next().unwrap();
let capacity = u64::from_be_bytes(get_slice!(8).try_into().unwrap());
$first_hops_vec.push(ChannelDetails {
channel_id: ChannelId::new_zero(),
let count = get_slice!(1)[0];
for _ in 0..count {
scid += 1;
- let rnid = node_pks.iter().skip(slice_to_be16(get_slice!(2))as usize % node_pks.len()).next().unwrap();
+ let (rnid, _) =
+ node_pks.iter().skip(slice_to_be16(get_slice!(2)) as usize % node_pks.len()).next().unwrap();
$last_hops.push(RouteHint(vec![RouteHintHop {
src_node_id: *rnid,
short_channel_id: scid,
($first_hops: expr, $node_pks: expr, $route_params: expr) => {
let scorer = ProbabilisticScorer::new(ProbabilisticScoringDecayParameters::default(), &net_graph, &logger);
let random_seed_bytes: [u8; 32] = [get_slice!(1)[0]; 32];
- for target in $node_pks {
+ for (target, ()) in $node_pks {
let final_value_msat = slice_to_be64(get_slice!(8));
let final_cltv_expiry_delta = slice_to_be32(get_slice!(4));
let route_params = $route_params(final_value_msat, final_cltv_expiry_delta, target);
return;
}
let msg = decode_msg_with_len16!(msgs::UnsignedNodeAnnouncement, 288);
- node_pks.insert(get_pubkey_from_node_id!(msg.node_id));
+ node_pks.insert(get_pubkey_from_node_id!(msg.node_id), ());
let _ = net_graph.update_node_from_unsigned_announcement(&msg);
},
1 => {
let msg = decode_msg_with_len16!(msgs::UnsignedChannelAnnouncement, 32+8+33*4);
- node_pks.insert(get_pubkey_from_node_id!(msg.node_id_1));
- node_pks.insert(get_pubkey_from_node_id!(msg.node_id_2));
+ node_pks.insert(get_pubkey_from_node_id!(msg.node_id_1), ());
+ node_pks.insert(get_pubkey_from_node_id!(msg.node_id_2), ());
let _ = net_graph.update_channel_from_unsigned_announcement::
<&FuzzChainSource<'_, '_, Out>>(&msg, &None);
},
2 => {
let msg = decode_msg_with_len16!(msgs::UnsignedChannelAnnouncement, 32+8+33*4);
- node_pks.insert(get_pubkey_from_node_id!(msg.node_id_1));
- node_pks.insert(get_pubkey_from_node_id!(msg.node_id_2));
+ node_pks.insert(get_pubkey_from_node_id!(msg.node_id_1), ());
+ node_pks.insert(get_pubkey_from_node_id!(msg.node_id_2), ());
let _ = net_graph.update_channel_from_unsigned_announcement(&msg, &Some(&chain_source));
},
3 => {
}).collect();
let mut features = Bolt12InvoiceFeatures::empty();
features.set_basic_mpp_optional();
- find_routes!(first_hops, vec![dummy_pk].iter(), |final_amt, _, _| {
+ find_routes!(first_hops, [(dummy_pk, ())].iter(), |final_amt, _, _| {
RouteParameters::from_payment_params_and_value(PaymentParameters::blinded(last_hops.clone())
.with_bolt12_features(features.clone()).unwrap(),
final_amt)
# Override signing to not include randomness when generating signatures for test vectors.
_test_vectors = []
-no-std = ["hashbrown", "ahash", "bitcoin/no-std", "core2/alloc", "libm"]
+no-std = ["hashbrown", "possiblyrandom", "bitcoin/no-std", "core2/alloc", "libm"]
std = ["bitcoin/std"]
# Generates low-r bitcoin signatures, which saves 1 byte in 50% of the cases
[dependencies]
bitcoin = { version = "0.30.2", default-features = false, features = ["secp-recovery"] }
-hashbrown = { version = "0.13", optional = true }
-ahash = { version = "0.8", optional = true, default-features = false }
+hashbrown = { version = "0.13", optional = true, default-features = false }
+possiblyrandom = { version = "0.1", optional = true, default-features = false }
hex = { package = "hex-conservative", version = "0.1.1", default-features = false }
regex = { version = "1.5.6", optional = true }
backtrace = { version = "0.3", optional = true }
core2 = { version = "0.3.0", optional = true, default-features = false }
libm = { version = "0.2", optional = true, default-features = false }
-# Because ahash no longer (kinda poorly) does it for us, (roughly) list out the targets that
-# getrandom supports and turn on ahash's `runtime-rng` feature for them.
-[target.'cfg(not(any(target_os = "unknown", target_os = "none")))'.dependencies]
-ahash = { version = "0.8", optional = true, default-features = false, features = ["runtime-rng"] }
-
-# Not sure what target_os gets set to for sgx, so to be safe always enable runtime-rng for x86_64
-# platforms (assuming LDK isn't being used on embedded x86-64 running directly on metal).
-[target.'cfg(target_arch = "x86_64")'.dependencies]
-ahash = { version = "0.8", optional = true, default-features = false, features = ["runtime-rng"] }
-
[dev-dependencies]
regex = "1.5.6"
}
mod prelude {
- #[cfg(feature = "hashbrown")]
- extern crate hashbrown;
- #[cfg(feature = "ahash")]
- extern crate ahash;
-
pub use alloc::{vec, vec::Vec, string::String, collections::VecDeque, boxed::Box};
pub use alloc::borrow::ToOwned;
pub use alloc::string::ToString;
- // For no-std builds, we need to use hashbrown, however, by default, it doesn't randomize the
- // hashing and is vulnerable to HashDoS attacks. Thus, when not fuzzing, we use its default
- // ahash hashing algorithm but randomize, opting to not randomize when fuzzing to avoid false
- // positive branch coverage.
-
- #[cfg(not(feature = "hashbrown"))]
- mod std_hashtables {
- pub(crate) use std::collections::{HashMap, HashSet, hash_map};
-
- pub(crate) type OccupiedHashMapEntry<'a, K, V> =
- std::collections::hash_map::OccupiedEntry<'a, K, V>;
- pub(crate) type VacantHashMapEntry<'a, K, V> =
- std::collections::hash_map::VacantEntry<'a, K, V>;
- }
- #[cfg(not(feature = "hashbrown"))]
- pub(crate) use std_hashtables::*;
-
- #[cfg(feature = "hashbrown")]
- pub(crate) use self::hashbrown::hash_map;
-
- #[cfg(all(feature = "hashbrown", fuzzing))]
- mod nonrandomized_hashbrown {
- pub(crate) use hashbrown::{HashMap, HashSet};
-
- pub(crate) type OccupiedHashMapEntry<'a, K, V> =
- hashbrown::hash_map::OccupiedEntry<'a, K, V, hashbrown::hash_map::DefaultHashBuilder>;
- pub(crate) type VacantHashMapEntry<'a, K, V> =
- hashbrown::hash_map::VacantEntry<'a, K, V, hashbrown::hash_map::DefaultHashBuilder>;
- }
- #[cfg(all(feature = "hashbrown", fuzzing))]
- pub(crate) use nonrandomized_hashbrown::*;
-
-
- #[cfg(all(feature = "hashbrown", not(fuzzing)))]
- mod randomized_hashtables {
- use super::*;
- use ahash::RandomState;
-
- pub(crate) type HashMap<K, V> = hashbrown::HashMap<K, V, RandomState>;
- pub(crate) type HashSet<K> = hashbrown::HashSet<K, RandomState>;
-
- pub(crate) type OccupiedHashMapEntry<'a, K, V> =
- hashbrown::hash_map::OccupiedEntry<'a, K, V, RandomState>;
- pub(crate) type VacantHashMapEntry<'a, K, V> =
- hashbrown::hash_map::VacantEntry<'a, K, V, RandomState>;
-
- pub(crate) fn new_hash_map<K, V>() -> HashMap<K, V> {
- HashMap::with_hasher(RandomState::new())
- }
- pub(crate) fn hash_map_with_capacity<K, V>(cap: usize) -> HashMap<K, V> {
- HashMap::with_capacity_and_hasher(cap, RandomState::new())
- }
- pub(crate) fn hash_map_from_iter<K: core::hash::Hash + Eq, V, I: IntoIterator<Item=(K, V)>>(iter: I) -> HashMap<K, V> {
- let iter = iter.into_iter();
- let min_size = iter.size_hint().0;
- let mut res = HashMap::with_capacity_and_hasher(min_size, RandomState::new());
- res.extend(iter);
- res
- }
-
- pub(crate) fn new_hash_set<K>() -> HashSet<K> {
- HashSet::with_hasher(RandomState::new())
- }
- pub(crate) fn hash_set_with_capacity<K>(cap: usize) -> HashSet<K> {
- HashSet::with_capacity_and_hasher(cap, RandomState::new())
- }
- pub(crate) fn hash_set_from_iter<K: core::hash::Hash + Eq, I: IntoIterator<Item=K>>(iter: I) -> HashSet<K> {
- let iter = iter.into_iter();
- let min_size = iter.size_hint().0;
- let mut res = HashSet::with_capacity_and_hasher(min_size, RandomState::new());
- res.extend(iter);
- res
- }
- }
-
- #[cfg(any(not(feature = "hashbrown"), fuzzing))]
- mod randomized_hashtables {
- use super::*;
-
- pub(crate) fn new_hash_map<K, V>() -> HashMap<K, V> { HashMap::new() }
- pub(crate) fn hash_map_with_capacity<K, V>(cap: usize) -> HashMap<K, V> {
- HashMap::with_capacity(cap)
- }
- pub(crate) fn hash_map_from_iter<K: core::hash::Hash + Eq, V, I: IntoIterator<Item=(K, V)>>(iter: I) -> HashMap<K, V> {
- HashMap::from_iter(iter)
- }
-
- pub(crate) fn new_hash_set<K>() -> HashSet<K> { HashSet::new() }
- pub(crate) fn hash_set_with_capacity<K>(cap: usize) -> HashSet<K> {
- HashSet::with_capacity(cap)
- }
- pub(crate) fn hash_set_from_iter<K: core::hash::Hash + Eq, I: IntoIterator<Item=K>>(iter: I) -> HashSet<K> {
- HashSet::from_iter(iter)
- }
- }
-
- pub(crate) use randomized_hashtables::*;
+ pub(crate) use crate::util::hash_tables::*;
}
#[cfg(all(not(ldk_bench), feature = "backtrace", feature = "std", test))]
--- /dev/null
+//! Generally LDK uses `std`'s `HashMap`s, however when building for no-std, LDK uses `hashbrown`'s
+//! `HashMap`s with the `std` `SipHasher` and uses `getrandom` to opportunistically randomize it,
+//! if randomization is available.
+//!
+//! This module simply re-exports the `HashMap` used in LDK for public consumption.
+
+#[cfg(feature = "hashbrown")]
+extern crate hashbrown;
+#[cfg(feature = "possiblyrandom")]
+extern crate possiblyrandom;
+
+// For no-std builds, we need to use hashbrown, however, by default, it doesn't randomize the
+// hashing and is vulnerable to HashDoS attacks. Thus, we use the core SipHasher when not using
+// std, but use `getrandom` to randomize it if its available.
+
+#[cfg(not(feature = "hashbrown"))]
+mod std_hashtables {
+ pub use std::collections::HashMap;
+ pub use std::collections::hash_map::RandomState;
+
+ pub(crate) use std::collections::{HashSet, hash_map};
+
+ pub(crate) type OccupiedHashMapEntry<'a, K, V> =
+ std::collections::hash_map::OccupiedEntry<'a, K, V>;
+ pub(crate) type VacantHashMapEntry<'a, K, V> =
+ std::collections::hash_map::VacantEntry<'a, K, V>;
+
+ /// Builds a new [`HashMap`].
+ pub fn new_hash_map<K, V>() -> HashMap<K, V> { HashMap::new() }
+ /// Builds a new [`HashMap`] with the given capacity.
+ pub fn hash_map_with_capacity<K, V>(cap: usize) -> HashMap<K, V> {
+ HashMap::with_capacity(cap)
+ }
+ pub(crate) fn hash_map_from_iter<K: core::hash::Hash + Eq, V, I: IntoIterator<Item=(K, V)>>(iter: I) -> HashMap<K, V> {
+ HashMap::from_iter(iter)
+ }
+
+ pub(crate) fn new_hash_set<K>() -> HashSet<K> { HashSet::new() }
+ pub(crate) fn hash_set_with_capacity<K>(cap: usize) -> HashSet<K> {
+ HashSet::with_capacity(cap)
+ }
+ pub(crate) fn hash_set_from_iter<K: core::hash::Hash + Eq, I: IntoIterator<Item=K>>(iter: I) -> HashSet<K> {
+ HashSet::from_iter(iter)
+ }
+}
+#[cfg(not(feature = "hashbrown"))]
+pub use std_hashtables::*;
+
+#[cfg(feature = "hashbrown")]
+pub(crate) use self::hashbrown::hash_map;
+
+#[cfg(feature = "hashbrown")]
+mod hashbrown_tables {
+ #[cfg(feature = "std")]
+ mod hasher {
+ pub use std::collections::hash_map::RandomState;
+ }
+ #[cfg(not(feature = "std"))]
+ mod hasher {
+ #![allow(deprecated)] // hash::SipHasher was deprecated in favor of something only in std.
+ use core::hash::{BuildHasher, SipHasher};
+
+ #[derive(Clone, Copy)]
+ /// A simple implementation of [`BuildHasher`] that uses `getrandom` to opportunistically
+ /// randomize, if the platform supports it.
+ pub struct RandomState {
+ k0: u64, k1: u64,
+ }
+
+ impl RandomState {
+ /// Constructs a new [`RandomState`] which may or may not be random, depending on the
+ /// target platform.
+ pub fn new() -> RandomState {
+ let (k0, k1);
+ #[cfg(all(not(fuzzing), feature = "possiblyrandom"))] {
+ let mut keys = [0; 16];
+ possiblyrandom::getpossiblyrandom(&mut keys);
+
+ let mut k0_bytes = [0; 8];
+ let mut k1_bytes = [0; 8];
+ k0_bytes.copy_from_slice(&keys[..8]);
+ k1_bytes.copy_from_slice(&keys[8..]);
+ k0 = u64::from_le_bytes(k0_bytes);
+ k1 = u64::from_le_bytes(k1_bytes);
+ }
+ #[cfg(any(fuzzing, not(feature = "possiblyrandom")))] {
+ k0 = 0;
+ k1 = 0;
+ }
+ RandomState { k0, k1 }
+ }
+ }
+
+ impl Default for RandomState {
+ fn default() -> RandomState { RandomState::new() }
+ }
+
+ impl BuildHasher for RandomState {
+ type Hasher = SipHasher;
+ fn build_hasher(&self) -> SipHasher {
+ SipHasher::new_with_keys(self.k0, self.k1)
+ }
+ }
+ }
+
+ pub use hasher::*;
+ use super::*;
+
+ /// The HashMap type used in LDK.
+ pub type HashMap<K, V> = hashbrown::HashMap<K, V, RandomState>;
+ pub(crate) type HashSet<K> = hashbrown::HashSet<K, RandomState>;
+
+ pub(crate) type OccupiedHashMapEntry<'a, K, V> =
+ hashbrown::hash_map::OccupiedEntry<'a, K, V, RandomState>;
+ pub(crate) type VacantHashMapEntry<'a, K, V> =
+ hashbrown::hash_map::VacantEntry<'a, K, V, RandomState>;
+
+ /// Builds a new [`HashMap`].
+ pub fn new_hash_map<K, V>() -> HashMap<K, V> {
+ HashMap::with_hasher(RandomState::new())
+ }
+ /// Builds a new [`HashMap`] with the given capacity.
+ pub fn hash_map_with_capacity<K, V>(cap: usize) -> HashMap<K, V> {
+ HashMap::with_capacity_and_hasher(cap, RandomState::new())
+ }
+ pub(crate) fn hash_map_from_iter<K: core::hash::Hash + Eq, V, I: IntoIterator<Item=(K, V)>>(iter: I) -> HashMap<K, V> {
+ let iter = iter.into_iter();
+ let min_size = iter.size_hint().0;
+ let mut res = HashMap::with_capacity_and_hasher(min_size, RandomState::new());
+ res.extend(iter);
+ res
+ }
+
+ pub(crate) fn new_hash_set<K>() -> HashSet<K> {
+ HashSet::with_hasher(RandomState::new())
+ }
+ pub(crate) fn hash_set_with_capacity<K>(cap: usize) -> HashSet<K> {
+ HashSet::with_capacity_and_hasher(cap, RandomState::new())
+ }
+ pub(crate) fn hash_set_from_iter<K: core::hash::Hash + Eq, I: IntoIterator<Item=K>>(iter: I) -> HashSet<K> {
+ let iter = iter.into_iter();
+ let min_size = iter.size_hint().0;
+ let mut res = HashSet::with_capacity_and_hasher(min_size, RandomState::new());
+ res.extend(iter);
+ res
+ }
+}
+#[cfg(feature = "hashbrown")]
+pub use hashbrown_tables::*;
pub(crate) mod byte_utils;
pub(crate) mod transaction_utils;
pub(crate) mod time;
+pub mod hash_tables;
pub mod indexed_map;