Ingest duplicate proofs sent through Gossip (#29227)

* First draft of ingesting duplicate proofs in Gossip into blockstore.

* Add more unittests.

* Add more unittests for bad cases.

* Fix lint errors for tests.

* More linter fixes for tests.

* Lint fixes

* Rename get_entries, move location of comment.

* Some renaming changes and comment fixes.

* Fix compile warning, this enum is not used.

* Fix lint errors.

* Slow down cleanup because this could potentially be expensive.

* Forgot to reset cleanup count.

* Add protection against attackers when constructing chunk map when
we ingest Gossip proofs.

* Use duplicate shred index instead of get_entries.

* Rename ClusterInfoDuplicateShredListener and fix a few small problems.

* Use into_shreds to piece together the proof.

* Remove redundant code.

* Address a few small errors.

* Discard slots too advanced in the future.

* - Use oldest proof for each pubkey
- Limit number of pubkeys in each slot to 100

* Disable duplicate shred handling for now.

* Revert "Disable duplicate shred handling for now."

This reverts commit c3fcf403876cfbf90afe4d2265a826f21a5e24ab.
This commit is contained in:
Wen 2023-01-19 13:00:56 -08:00 committed by GitHub
parent 9fa3cb659c
commit b36791956e
No known key found for this signature in database
GPG Key ID: 4AEE18F83AFDEB23
7 changed files with 665 additions and 2 deletions

1
.gitignore vendored
View File

@ -1,3 +1,4 @@
/dos/farf/
/farf/
/solana-release/
/solana-release.tar.bz2

View File

@ -30,7 +30,10 @@ use {
crossbeam_channel::{unbounded, Receiver},
solana_client::connection_cache::ConnectionCache,
solana_geyser_plugin_manager::block_metadata_notifier_interface::BlockMetadataNotifierLock,
solana_gossip::cluster_info::ClusterInfo,
solana_gossip::{
cluster_info::ClusterInfo, duplicate_shred_handler::DuplicateShredHandler,
duplicate_shred_listener::DuplicateShredListener,
},
solana_ledger::{
blockstore::Blockstore, blockstore_processor::TransactionStatusSender,
leader_schedule_cache::LeaderScheduleCache,
@ -66,6 +69,7 @@ pub struct Tvu {
voting_service: VotingService,
warm_quic_cache_service: Option<WarmQuicCacheService>,
drop_bank_service: DropBankService,
duplicate_shred_listener: DuplicateShredListener,
}
pub struct TvuSockets {
@ -306,6 +310,12 @@ impl Tvu {
)
});
let duplicate_shred_listener = DuplicateShredListener::new(
exit.clone(),
cluster_info.clone(),
DuplicateShredHandler::new(blockstore, leader_schedule_cache.clone()),
);
Ok(Tvu {
fetch_stage,
shred_sigverify,
@ -318,6 +328,7 @@ impl Tvu {
voting_service,
warm_quic_cache_service,
drop_bank_service,
duplicate_shred_listener,
})
}
@ -337,6 +348,7 @@ impl Tvu {
warmup_service.join()?;
}
self.drop_bank_service.join()?;
self.duplicate_shred_listener.join()?;
Ok(())
}
}

View File

@ -111,7 +111,7 @@ const MAX_GOSSIP_TRAFFIC: usize = 128_000_000 / PACKET_DATA_SIZE;
/// is equal to PACKET_DATA_SIZE minus serialized size of an empty push
/// message: Protocol::PushMessage(Pubkey::default(), Vec::default())
const PUSH_MESSAGE_MAX_PAYLOAD_SIZE: usize = PACKET_DATA_SIZE - 44;
const DUPLICATE_SHRED_MAX_PAYLOAD_SIZE: usize = PACKET_DATA_SIZE - 115;
pub(crate) const DUPLICATE_SHRED_MAX_PAYLOAD_SIZE: usize = PACKET_DATA_SIZE - 115;
/// Maximum number of hashes in SnapshotHashes/AccountsHashes a node publishes
/// such that the serialized size of the push/pull message stays below
/// PACKET_DATA_SIZE.
@ -4709,4 +4709,55 @@ RPC Enabled Nodes: 1"#;
DEFAULT_SLOTS_PER_EPOCH * DEFAULT_MS_PER_SLOT // 48 hours
);
}
#[test]
fn test_get_duplicate_shreds() {
let node = Node::new_localhost();
let host1_key = Arc::new(Keypair::new());
let cluster_info = Arc::new(ClusterInfo::new(
node.info,
host1_key.clone(),
SocketAddrSpace::Unspecified,
));
let mut cursor = Cursor::default();
assert!(cluster_info.get_duplicate_shreds(&mut cursor).is_empty());
let mut rng = rand::thread_rng();
let (slot, parent_slot, reference_tick, version) = (53084024, 53084023, 0, 0);
let shredder = Shredder::new(slot, parent_slot, reference_tick, version).unwrap();
let next_shred_index = 353;
let leader = Arc::new(Keypair::new());
let shred1 = new_rand_shred(&mut rng, next_shred_index, &shredder, &leader);
let shred2 = new_rand_shred(&mut rng, next_shred_index, &shredder, &leader);
assert!(cluster_info
.push_duplicate_shred(&shred1, shred2.payload())
.is_ok());
cluster_info.flush_push_queue();
let entries = cluster_info.get_duplicate_shreds(&mut cursor);
// One duplicate shred proof is split into 3 chunks.
assert_eq!(3, entries.len());
for (i, shred_data) in entries.iter().enumerate() {
assert_eq!(shred_data.from, host1_key.pubkey());
assert_eq!(shred_data.slot, 53084024);
assert_eq!(shred_data.chunk_index() as usize, i);
}
let slot = 53084025;
let shredder = Shredder::new(slot, parent_slot, reference_tick, version).unwrap();
let next_shred_index = 354;
let shred3 = new_rand_shred(&mut rng, next_shred_index, &shredder, &leader);
let shred4 = new_rand_shred(&mut rng, next_shred_index, &shredder, &leader);
assert!(cluster_info
.push_duplicate_shred(&shred3, shred4.payload())
.is_ok());
cluster_info.flush_push_queue();
let entries1 = cluster_info.get_duplicate_shreds(&mut cursor);
// One duplicate shred proof is split into 3 chunks.
assert_eq!(3, entries1.len());
for (i, shred_data) in entries1.iter().enumerate() {
assert_eq!(shred_data.from, host1_key.pubkey());
assert_eq!(shred_data.slot, 53084025);
assert_eq!(shred_data.chunk_index() as usize, i);
}
}
}

View File

@ -2,6 +2,7 @@ use {
crate::crds_value::sanitize_wallclock,
itertools::Itertools,
solana_ledger::{
blockstore::BlockstoreError,
blockstore_meta::DuplicateSlotProof,
shred::{self, Shred, ShredType},
},
@ -41,8 +42,19 @@ pub struct DuplicateShred {
chunk: Vec<u8>,
}
impl DuplicateShred {
pub(crate) fn num_chunks(&self) -> u8 {
self.num_chunks
}
pub(crate) fn chunk_index(&self) -> u8 {
self.chunk_index
}
}
#[derive(Debug, Error)]
pub enum Error {
#[error("block store save error")]
BlockstoreInsertFailed(#[from] BlockstoreError),
#[error("data chunk mismatch")]
DataChunkMismatch,
#[error("invalid chunk index")]

View File

@ -0,0 +1,456 @@
use {
crate::{
duplicate_shred::{into_shreds, DuplicateShred, Error},
duplicate_shred_listener::DuplicateShredHandlerTrait,
},
log::*,
lru::LruCache,
solana_ledger::{blockstore::Blockstore, leader_schedule_cache::LeaderScheduleCache},
solana_sdk::{clock::Slot, pubkey::Pubkey},
std::{
collections::{HashMap, HashSet},
sync::Arc,
},
};
const CLEANUP_EVERY_N_LOOPS: usize = 10;
// Normally num_chunks is 3, because there are two shreds (each is one packet)
// and meta data. So we discard anything larger than 3 chunks.
const MAX_NUM_CHUNKS: u8 = 3;
// We only allow each pubkey to send proofs for 5 slots, because normally there
// is only 1 person sending out duplicate proofs, 1 person is leader for 4 slots,
// so we allow 5 here to limit the chunk map size.
const ALLOWED_SLOTS_PER_PUBKEY: usize = 5;
// To prevent an attacker inflating this map, we discard any proof which is too
// far away in the future compared to root.
const MAX_SLOT_DISTANCE_TO_ROOT: Slot = 100;
// We limit the pubkey for each slot to be 100 for now.
const MAX_PUBKEY_PER_SLOT: usize = 100;
struct ProofChunkMap {
num_chunks: u8,
wallclock: u64,
chunks: HashMap<u8, DuplicateShred>,
}
impl ProofChunkMap {
fn new(num_chunks: u8, wallclock: u64) -> Self {
Self {
num_chunks,
chunks: HashMap::new(),
wallclock,
}
}
}
// Group received chunks by peer pubkey, when we receive an invalid proof,
// set the value to Frozen so we don't accept future proofs with the same key.
type SlotChunkMap = LruCache<Pubkey, ProofChunkMap>;
enum SlotStatus {
// When a valid proof has been inserted, we change the entry for that slot to Frozen
// to indicate we no longer accept proofs for this slot.
Frozen,
UnfinishedProof(SlotChunkMap),
}
pub struct DuplicateShredHandler {
// Because we use UDP for packet transfer, we can normally only send ~1500 bytes
// in each packet. We send both shreds and meta data in duplicate shred proof, and
// each shred is normally 1 packet(1500 bytes), so the whole proof is larger than
// 1 packet and it needs to be cut down as chunks for transfer. So we need to piece
// together the chunks into the original proof before anything useful is done.
chunk_map: HashMap<Slot, SlotStatus>,
// We don't want bad guys to inflate the chunk map, so we limit the number of
// pending proofs from each pubkey to ALLOWED_SLOTS_PER_PUBKEY.
validator_pending_proof_map: HashMap<Pubkey, HashSet<Slot>>,
// remember the last root slot handled, clear anything older than last_root.
last_root: Slot,
blockstore: Arc<Blockstore>,
leader_schedule_cache: Arc<LeaderScheduleCache>,
// Because cleanup could potentially be very expensive, only clean up when clean up
// count is 0
cleanup_count: usize,
}
impl DuplicateShredHandlerTrait for DuplicateShredHandler {
// Here we are sending data one by one rather than in a batch because in the future
// we may send different type of CrdsData to different senders.
fn handle(&mut self, shred_data: DuplicateShred) {
if let Err(error) = self.handle_shred_data(shred_data) {
error!("handle packet: {:?}", error)
}
if self.cleanup_count.saturating_sub(1) == 0 {
self.cleanup_old_slots();
self.cleanup_count = CLEANUP_EVERY_N_LOOPS;
}
}
}
impl DuplicateShredHandler {
pub fn new(
blockstore: Arc<Blockstore>,
leader_schedule_cache: Arc<LeaderScheduleCache>,
) -> Self {
Self {
chunk_map: HashMap::new(),
validator_pending_proof_map: HashMap::new(),
last_root: 0,
blockstore,
leader_schedule_cache,
cleanup_count: CLEANUP_EVERY_N_LOOPS,
}
}
fn handle_shred_data(&mut self, data: DuplicateShred) -> Result<(), Error> {
if self.should_insert_chunk(&data) {
let slot = data.slot;
match self.insert_chunk(data) {
Err(error) => return Err(error),
Ok(Some(chunks)) => {
self.verify_and_apply_proof(slot, chunks)?;
// We stored the duplicate proof in this slot, no need to accept any future proof.
self.mark_slot_proof_received(slot);
}
_ => (),
}
}
Ok(())
}
fn should_insert_chunk(&self, data: &DuplicateShred) -> bool {
let slot = data.slot;
// Do not insert if this slot is rooted or too far away in the future or has a proof already.
let last_root = self.blockstore.last_root();
if slot <= last_root
|| slot > last_root + MAX_SLOT_DISTANCE_TO_ROOT
|| self.blockstore.has_duplicate_shreds_in_slot(slot)
{
return false;
}
// Discard all proofs with abnormal num_chunks.
if data.num_chunks() == 0 || data.num_chunks() > MAX_NUM_CHUNKS {
return false;
}
// Only allow limited unfinished proofs per pubkey to reject attackers.
if let Some(current_slots_set) = self.validator_pending_proof_map.get(&data.from) {
if !current_slots_set.contains(&slot)
&& current_slots_set.len() >= ALLOWED_SLOTS_PER_PUBKEY
{
return false;
}
}
// Also skip frozen slots or slots with an older proof than me.
match self.chunk_map.get(&slot) {
Some(SlotStatus::Frozen) => {
return false;
}
Some(SlotStatus::UnfinishedProof(slot_map)) => {
if let Some(proof_chunkmap) = slot_map.peek(&data.from) {
if proof_chunkmap.wallclock < data.wallclock {
return false;
}
}
}
None => {}
}
true
}
fn mark_slot_proof_received(&mut self, slot: u64) {
self.chunk_map.insert(slot, SlotStatus::Frozen);
for (_, current_slots_set) in self.validator_pending_proof_map.iter_mut() {
current_slots_set.remove(&slot);
}
}
fn insert_chunk(&mut self, data: DuplicateShred) -> Result<Option<Vec<DuplicateShred>>, Error> {
if let SlotStatus::UnfinishedProof(slot_chunk_map) = self
.chunk_map
.entry(data.slot)
.or_insert_with(|| SlotStatus::UnfinishedProof(LruCache::new(MAX_PUBKEY_PER_SLOT)))
{
if !slot_chunk_map.contains(&data.from) {
slot_chunk_map.put(
data.from,
ProofChunkMap::new(data.num_chunks(), data.wallclock),
);
}
if let Some(mut proof_chunk_map) = slot_chunk_map.get_mut(&data.from) {
if proof_chunk_map.wallclock > data.wallclock {
proof_chunk_map.num_chunks = data.num_chunks();
proof_chunk_map.wallclock = data.wallclock;
proof_chunk_map.chunks.clear();
}
let num_chunks = data.num_chunks();
let chunk_index = data.chunk_index();
let slot = data.slot;
let from = data.from;
if num_chunks == proof_chunk_map.num_chunks
&& chunk_index < num_chunks
&& !proof_chunk_map.chunks.contains_key(&chunk_index)
{
proof_chunk_map.chunks.insert(chunk_index, data);
if proof_chunk_map.chunks.len() >= proof_chunk_map.num_chunks.into() {
let mut result: Vec<DuplicateShred> = Vec::new();
for i in 0..num_chunks {
result.push(proof_chunk_map.chunks.remove(&i).unwrap())
}
return Ok(Some(result));
}
}
self.validator_pending_proof_map
.entry(from)
.or_default()
.insert(slot);
}
}
Ok(None)
}
fn verify_and_apply_proof(&self, slot: Slot, chunks: Vec<DuplicateShred>) -> Result<(), Error> {
if slot <= self.blockstore.last_root() || self.blockstore.has_duplicate_shreds_in_slot(slot)
{
return Ok(());
}
let (shred1, shred2) = into_shreds(chunks, |slot| {
self.leader_schedule_cache.slot_leader_at(slot, None)
})?;
self.blockstore
.store_duplicate_slot(slot, shred1.into_payload(), shred2.into_payload())?;
Ok(())
}
fn cleanup_old_slots(&mut self) {
let new_last_root = self.blockstore.last_root();
if self.last_root < new_last_root {
self.chunk_map.retain(|k, _| k > &new_last_root);
for (_, slots_sets) in self.validator_pending_proof_map.iter_mut() {
slots_sets.retain(|k| k > &new_last_root);
}
self.last_root = new_last_root
}
}
}
#[cfg(test)]
mod tests {
use {
super::*,
crate::{
cluster_info::DUPLICATE_SHRED_MAX_PAYLOAD_SIZE,
duplicate_shred::{from_shred, tests::new_rand_shred, DuplicateShred, Error},
duplicate_shred_listener::DuplicateShredHandlerTrait,
},
solana_ledger::{
genesis_utils::{create_genesis_config_with_leader, GenesisConfigInfo},
get_tmp_ledger_path_auto_delete,
shred::Shredder,
},
solana_runtime::{bank::Bank, bank_forks::BankForks},
solana_sdk::{
signature::{Keypair, Signer},
timing::timestamp,
},
std::sync::Arc,
};
fn create_duplicate_proof(
keypair: Arc<Keypair>,
slot: u64,
expected_error: Option<Error>,
chunk_size: usize,
) -> Result<Box<dyn Iterator<Item = DuplicateShred>>, Error> {
let my_keypair = match expected_error {
Some(Error::InvalidSignature) => Arc::new(Keypair::new()),
_ => keypair,
};
let mut rng = rand::thread_rng();
let shredder = Shredder::new(slot, slot - 1, 0, 0).unwrap();
let next_shred_index = 353;
let shred1 = new_rand_shred(&mut rng, next_shred_index, &shredder, &my_keypair);
let shredder1 = Shredder::new(slot + 1, slot, 0, 0).unwrap();
let shred2 = match expected_error {
Some(Error::SlotMismatch) => {
new_rand_shred(&mut rng, next_shred_index, &shredder1, &my_keypair)
}
Some(Error::ShredIndexMismatch) => {
new_rand_shred(&mut rng, next_shred_index + 1, &shredder, &my_keypair)
}
Some(Error::InvalidDuplicateShreds) => shred1.clone(),
_ => new_rand_shred(&mut rng, next_shred_index, &shredder, &my_keypair),
};
let chunks = from_shred(
shred1,
my_keypair.pubkey(),
shred2.payload().clone(),
None::<fn(Slot) -> Option<Pubkey>>,
timestamp(), // wallclock
chunk_size, // max_size
)?;
Ok(Box::new(chunks))
}
#[test]
fn test_handle_mixed_entries() {
solana_logger::setup();
let ledger_path = get_tmp_ledger_path_auto_delete!();
let blockstore = Arc::new(Blockstore::open(ledger_path.path()).unwrap());
let my_keypair = Arc::new(Keypair::new());
let my_pubkey = my_keypair.pubkey();
let genesis_config_info = create_genesis_config_with_leader(10_000, &my_pubkey, 10_000);
let GenesisConfigInfo { genesis_config, .. } = genesis_config_info;
let bank_forks = BankForks::new(Bank::new_for_tests(&genesis_config));
let leader_schedule_cache = Arc::new(LeaderScheduleCache::new_from_bank(
&bank_forks.working_bank(),
));
let mut duplicate_shred_handler =
DuplicateShredHandler::new(blockstore.clone(), leader_schedule_cache);
let chunks = create_duplicate_proof(
my_keypair.clone(),
1,
None,
DUPLICATE_SHRED_MAX_PAYLOAD_SIZE,
)
.unwrap();
let chunks1 = create_duplicate_proof(
my_keypair.clone(),
2,
None,
DUPLICATE_SHRED_MAX_PAYLOAD_SIZE,
)
.unwrap();
assert!(!blockstore.has_duplicate_shreds_in_slot(1));
assert!(!blockstore.has_duplicate_shreds_in_slot(2));
// Test that two proofs are mixed together, but we can store the proofs fine.
for (chunk1, chunk2) in chunks.zip(chunks1) {
duplicate_shred_handler.handle(chunk1);
duplicate_shred_handler.handle(chunk2);
}
assert!(blockstore.has_duplicate_shreds_in_slot(1));
assert!(blockstore.has_duplicate_shreds_in_slot(2));
// Test all kinds of bad proofs.
for error in [
Error::InvalidSignature,
Error::SlotMismatch,
Error::ShredIndexMismatch,
Error::InvalidDuplicateShreds,
] {
match create_duplicate_proof(
my_keypair.clone(),
3,
Some(error),
DUPLICATE_SHRED_MAX_PAYLOAD_SIZE,
) {
Err(_) => (),
Ok(chunks) => {
for chunk in chunks {
duplicate_shred_handler.handle(chunk);
}
assert!(!blockstore.has_duplicate_shreds_in_slot(3));
}
}
}
}
#[test]
fn test_reject_abuses() {
solana_logger::setup();
let ledger_path = get_tmp_ledger_path_auto_delete!();
let blockstore = Arc::new(Blockstore::open(ledger_path.path()).unwrap());
let my_keypair = Arc::new(Keypair::new());
let my_pubkey = my_keypair.pubkey();
let genesis_config_info = create_genesis_config_with_leader(10_000, &my_pubkey, 10_000);
let GenesisConfigInfo { genesis_config, .. } = genesis_config_info;
let bank_forks = BankForks::new(Bank::new_for_tests(&genesis_config));
let leader_schedule_cache = Arc::new(LeaderScheduleCache::new_from_bank(
&bank_forks.working_bank(),
));
let mut duplicate_shred_handler =
DuplicateShredHandler::new(blockstore.clone(), leader_schedule_cache);
// This proof will not be accepted because num_chunks is too large.
let chunks = create_duplicate_proof(
my_keypair.clone(),
1,
None,
DUPLICATE_SHRED_MAX_PAYLOAD_SIZE / 10,
)
.unwrap();
for chunk in chunks {
duplicate_shred_handler.handle(chunk);
}
assert!(!blockstore.has_duplicate_shreds_in_slot(1));
// This proof will be rejected because the slot is too far away in the future.
let future_slot = blockstore.last_root() + MAX_SLOT_DISTANCE_TO_ROOT + 1;
let chunks = create_duplicate_proof(
my_keypair.clone(),
future_slot,
None,
DUPLICATE_SHRED_MAX_PAYLOAD_SIZE / 10,
)
.unwrap();
for chunk in chunks {
duplicate_shred_handler.handle(chunk);
}
assert!(!blockstore.has_duplicate_shreds_in_slot(future_slot));
// Send in two proofs, only the proof with older wallclock will be accepted.
let chunks = create_duplicate_proof(
my_keypair.clone(),
1,
None,
DUPLICATE_SHRED_MAX_PAYLOAD_SIZE,
)
.unwrap();
let chunks1 = create_duplicate_proof(
my_keypair.clone(),
1,
None,
DUPLICATE_SHRED_MAX_PAYLOAD_SIZE,
)
.unwrap();
for (chunk1, chunk2) in chunks1.zip(chunks) {
duplicate_shred_handler.handle(chunk1);
// The first proof will never succeed because it's replaced in chunkmap by next one
// with older wallclock.
assert!(!blockstore.has_duplicate_shreds_in_slot(1));
duplicate_shred_handler.handle(chunk2);
}
// The second proof will succeed.
assert!(blockstore.has_duplicate_shreds_in_slot(1));
let mut all_chunks = vec![];
for i in 0..ALLOWED_SLOTS_PER_PUBKEY + 1 {
all_chunks.push(
create_duplicate_proof(
my_keypair.clone(),
(2 + i).try_into().unwrap(),
None,
DUPLICATE_SHRED_MAX_PAYLOAD_SIZE,
)
.unwrap(),
)
}
let mut done_count = 0;
let len = all_chunks.len();
while done_count < len {
done_count = 0;
for chunk_iterator in &mut all_chunks {
match chunk_iterator.next() {
Some(new_chunk) => duplicate_shred_handler.handle(new_chunk),
_ => done_count += 1,
}
}
}
for i in 0..ALLOWED_SLOTS_PER_PUBKEY {
assert!(blockstore.has_duplicate_shreds_in_slot((2 + i).try_into().unwrap()));
}
// The last proof should fail because we only allow limited entries per pubkey.
assert!(!blockstore
.has_duplicate_shreds_in_slot((2 + ALLOWED_SLOTS_PER_PUBKEY).try_into().unwrap()));
}
}

View File

@ -0,0 +1,129 @@
use {
crate::{
cluster_info::{ClusterInfo, GOSSIP_SLEEP_MILLIS},
crds::Cursor,
duplicate_shred::DuplicateShred,
},
std::{
sync::{
atomic::{AtomicBool, Ordering},
Arc,
},
thread::{self, sleep, Builder, JoinHandle},
time::Duration,
},
};
pub trait DuplicateShredHandlerTrait: Send {
fn handle(&mut self, data: DuplicateShred);
}
pub struct DuplicateShredListener {
thread_hdl: JoinHandle<()>,
}
// Right now we only need to process duplicate proof, in the future the receiver
// should be a map from enum value to handlers.
impl DuplicateShredListener {
pub fn new(
exit: Arc<AtomicBool>,
cluster_info: Arc<ClusterInfo>,
handler: impl DuplicateShredHandlerTrait + 'static,
) -> Self {
let listen_thread = Builder::new()
.name("solCiEntryLstnr".to_string())
.spawn(move || {
Self::recv_loop(exit, &cluster_info, handler);
})
.unwrap();
Self {
thread_hdl: listen_thread,
}
}
pub fn join(self) -> thread::Result<()> {
self.thread_hdl.join()
}
// Here we are sending data one by one rather than in a batch because in the future
// we may send different type of CrdsData to different senders.
fn recv_loop(
exit: Arc<AtomicBool>,
cluster_info: &ClusterInfo,
mut handler: impl DuplicateShredHandlerTrait + 'static,
) {
let mut cursor = Cursor::default();
while !exit.load(Ordering::Relaxed) {
let entries: Vec<DuplicateShred> = cluster_info.get_duplicate_shreds(&mut cursor);
for x in entries {
handler.handle(x);
}
sleep(Duration::from_millis(GOSSIP_SLEEP_MILLIS));
}
}
}
#[cfg(test)]
mod tests {
use {
super::*,
crate::{
cluster_info::Node, duplicate_shred::tests::new_rand_shred,
duplicate_shred_listener::DuplicateShredHandlerTrait,
},
solana_ledger::shred::Shredder,
solana_sdk::signature::Keypair,
solana_streamer::socket::SocketAddrSpace,
std::sync::{
atomic::{AtomicU32, Ordering},
Arc,
},
};
struct FakeHandler {
count: Arc<AtomicU32>,
}
impl FakeHandler {
pub fn new(count: Arc<AtomicU32>) -> Self {
Self { count }
}
}
impl DuplicateShredHandlerTrait for FakeHandler {
fn handle(&mut self, data: DuplicateShred) {
assert!(data.num_chunks() > 0);
self.count.fetch_add(1, Ordering::Relaxed);
}
}
#[test]
fn test_listener_get_entries() {
let node = Node::new_localhost();
let host1_key = Arc::new(Keypair::new());
let cluster_info = Arc::new(ClusterInfo::new(
node.info,
host1_key,
SocketAddrSpace::Unspecified,
));
let exit = Arc::new(AtomicBool::new(false));
let count = Arc::new(AtomicU32::new(0));
let handler = FakeHandler::new(count.clone());
let listener = DuplicateShredListener::new(exit.clone(), cluster_info.clone(), handler);
let mut rng = rand::thread_rng();
let (slot, parent_slot, reference_tick, version) = (53084024, 53084023, 0, 0);
let shredder = Shredder::new(slot, parent_slot, reference_tick, version).unwrap();
let next_shred_index = 353;
let leader = Arc::new(Keypair::new());
let shred1 = new_rand_shred(&mut rng, next_shred_index, &shredder, &leader);
let shred2 = new_rand_shred(&mut rng, next_shred_index, &shredder, &leader);
assert!(cluster_info
.push_duplicate_shred(&shred1, shred2.payload())
.is_ok());
cluster_info.flush_push_queue();
sleep(Duration::from_millis(GOSSIP_SLEEP_MILLIS));
assert_eq!(count.load(Ordering::Relaxed), 3);
exit.store(true, Ordering::Relaxed);
assert!(listener.join().is_ok());
}
}

View File

@ -13,6 +13,8 @@ pub mod crds_shards;
pub mod crds_value;
mod deprecated;
pub mod duplicate_shred;
pub mod duplicate_shred_handler;
pub mod duplicate_shred_listener;
pub mod epoch_slots;
pub mod gossip_error;
pub mod gossip_service;