Disable use of system time in tests

This commit is contained in:
Emilia Hane 2023-02-14 13:33:38 +01:00
parent 148385eb70
commit 73c7ad73b8
No known key found for this signature in database
GPG Key ID: E73394F9C09206FA
29 changed files with 485 additions and 559 deletions

View File

@ -1017,7 +1017,7 @@ fn descriptive_db_error(item: &str, error: &StoreError) -> String {
#[cfg(test)] #[cfg(test)]
mod test { mod test {
use super::*; use super::*;
use crate::test_utils::EphemeralTestingSlotClockHarnessType; use crate::test_utils::EphemeralHarnessType;
use crate::validator_monitor::DEFAULT_INDIVIDUAL_TRACKING_THRESHOLD; use crate::validator_monitor::DEFAULT_INDIVIDUAL_TRACKING_THRESHOLD;
use eth2_hashing::hash; use eth2_hashing::hash;
use genesis::{ use genesis::{
@ -1032,7 +1032,7 @@ mod test {
use types::{EthSpec, MinimalEthSpec, Slot}; use types::{EthSpec, MinimalEthSpec, Slot};
type TestEthSpec = MinimalEthSpec; type TestEthSpec = MinimalEthSpec;
type Builder = BeaconChainBuilder<EphemeralTestingSlotClockHarnessType<TestEthSpec>>; type Builder = BeaconChainBuilder<EphemeralHarnessType<TestEthSpec>>;
fn get_logger() -> Logger { fn get_logger() -> Logger {
let builder = NullLoggerBuilder; let builder = NullLoggerBuilder;

View File

@ -208,11 +208,11 @@ impl BlockShufflingIds {
#[cfg(test)] #[cfg(test)]
mod test { mod test {
use super::*; use super::*;
use crate::test_utils::EphemeralTestingSlotClockHarnessType; use crate::test_utils::EphemeralHarnessType;
use types::*; use types::*;
type BeaconChainHarness = type BeaconChainHarness =
crate::test_utils::BeaconChainHarness<EphemeralTestingSlotClockHarnessType<MinimalEthSpec>>; crate::test_utils::BeaconChainHarness<EphemeralHarnessType<MinimalEthSpec>>;
/// Returns two different committee caches for testing. /// Returns two different committee caches for testing.
fn committee_caches() -> (Arc<CommitteeCache>, Arc<CommitteeCache>) { fn committee_caches() -> (Arc<CommitteeCache>, Arc<CommitteeCache>) {

View File

@ -365,13 +365,13 @@ impl<T: EthSpec> SnapshotCache<T> {
#[cfg(test)] #[cfg(test)]
mod test { mod test {
use super::*; use super::*;
use crate::test_utils::{BeaconChainHarness, EphemeralTestingSlotClockHarnessType}; use crate::test_utils::{BeaconChainHarness, EphemeralHarnessType};
use types::{ use types::{
test_utils::generate_deterministic_keypair, BeaconBlock, Epoch, MainnetEthSpec, test_utils::generate_deterministic_keypair, BeaconBlock, Epoch, MainnetEthSpec,
SignedBeaconBlock, Slot, SignedBeaconBlock, Slot,
}; };
fn get_harness() -> BeaconChainHarness<EphemeralTestingSlotClockHarnessType<MainnetEthSpec>> { fn get_harness() -> BeaconChainHarness<EphemeralHarnessType<MainnetEthSpec>> {
let harness = BeaconChainHarness::builder(MainnetEthSpec) let harness = BeaconChainHarness::builder(MainnetEthSpec)
.default_spec() .default_spec()
.deterministic_keypairs(1) .deterministic_keypairs(1)

View File

@ -37,7 +37,7 @@ use sensitive_url::SensitiveUrl;
use slog::{o, Drain, Logger}; use slog::{o, Drain, Logger};
use slog_async::Async; use slog_async::Async;
use slog_term::{FullFormat, TermDecorator}; use slog_term::{FullFormat, TermDecorator};
use slot_clock::{SlotClock, SystemTimeSlotClock, TestingSlotClock}; use slot_clock::{SlotClock, TestingSlotClock};
use state_processing::per_block_processing::compute_timestamp_at_slot; use state_processing::per_block_processing::compute_timestamp_at_slot;
use state_processing::{ use state_processing::{
state_advance::{complete_state_advance, partial_state_advance}, state_advance::{complete_state_advance, partial_state_advance},
@ -67,25 +67,16 @@ const FORK_NAME_ENV_VAR: &str = "FORK_NAME";
// a different value. // a different value.
pub const DEFAULT_TARGET_AGGREGATORS: u64 = u64::max_value(); pub const DEFAULT_TARGET_AGGREGATORS: u64 = u64::max_value();
pub type BaseHarnessType<TEthSpec, THotStore, TColdStore, TSlotClock> = pub type BaseHarnessType<TEthSpec, THotStore, TColdStore> =
Witness<TSlotClock, CachingEth1Backend<TEthSpec>, TEthSpec, THotStore, TColdStore>; Witness<TestingSlotClock, CachingEth1Backend<TEthSpec>, TEthSpec, THotStore, TColdStore>;
pub type DiskHarnessType<E, TSlotClock> = BaseHarnessType<E, LevelDB<E>, LevelDB<E>, TSlotClock>; pub type DiskHarnessType<E> = BaseHarnessType<E, LevelDB<E>, LevelDB<E>>;
pub type EphemeralHarnessType<E> = BaseHarnessType<E, MemoryStore<E>, MemoryStore<E>>;
pub type EphemeralHarnessType<E, TSlotClock> = pub type BoxedMutator<E, Hot, Cold> = Box<
BaseHarnessType<E, MemoryStore<E>, MemoryStore<E>, TSlotClock>;
pub type EphemeralTestingSlotClockHarnessType<E> =
BaseHarnessType<E, MemoryStore<E>, MemoryStore<E>, TestingSlotClock>;
pub type EphemeralSystemTimeSlotClockHarnessType<E> =
BaseHarnessType<E, MemoryStore<E>, MemoryStore<E>, SystemTimeSlotClock>;
pub type TestingSlotClockHarnessType<E, THotStore, TColdStore> =
BaseHarnessType<E, THotStore, TColdStore, TestingSlotClock>;
pub type BoxedMutator<E, Hot, Cold, S> = Box<
dyn FnOnce( dyn FnOnce(
BeaconChainBuilder<BaseHarnessType<E, Hot, Cold, S>>, BeaconChainBuilder<BaseHarnessType<E, Hot, Cold>>,
) -> BeaconChainBuilder<BaseHarnessType<E, Hot, Cold, S>>, ) -> BeaconChainBuilder<BaseHarnessType<E, Hot, Cold>>,
>; >;
pub type AddBlocksResult<E> = ( pub type AddBlocksResult<E> = (
@ -157,7 +148,7 @@ pub fn test_spec<E: EthSpec>() -> ChainSpec {
spec spec
} }
pub struct Builder<T: BeaconChainTypes, S: SlotClock + 'static> { pub struct Builder<T: BeaconChainTypes> {
eth_spec_instance: T::EthSpec, eth_spec_instance: T::EthSpec,
spec: Option<ChainSpec>, spec: Option<ChainSpec>,
validator_keypairs: Option<Vec<Keypair>>, validator_keypairs: Option<Vec<Keypair>>,
@ -166,19 +157,17 @@ pub struct Builder<T: BeaconChainTypes, S: SlotClock + 'static> {
store_config: Option<StoreConfig>, store_config: Option<StoreConfig>,
#[allow(clippy::type_complexity)] #[allow(clippy::type_complexity)]
store: Option<Arc<HotColdDB<T::EthSpec, T::HotStore, T::ColdStore>>>, store: Option<Arc<HotColdDB<T::EthSpec, T::HotStore, T::ColdStore>>>,
#[allow(clippy::type_complexity)] initial_mutator: Option<BoxedMutator<T::EthSpec, T::HotStore, T::ColdStore>>,
initial_mutator: Option<BoxedMutator<T::EthSpec, T::HotStore, T::ColdStore, S>>, store_mutator: Option<BoxedMutator<T::EthSpec, T::HotStore, T::ColdStore>>,
#[allow(clippy::type_complexity)]
store_mutator: Option<BoxedMutator<T::EthSpec, T::HotStore, T::ColdStore, S>>,
execution_layer: Option<ExecutionLayer<T::EthSpec>>, execution_layer: Option<ExecutionLayer<T::EthSpec>>,
mock_execution_layer: Option<MockExecutionLayer<T::EthSpec>>, mock_execution_layer: Option<MockExecutionLayer<T::EthSpec>>,
mock_builder: Option<TestingBuilder<T::EthSpec>>, mock_builder: Option<TestingBuilder<T::EthSpec>>,
testing_slot_clock: Option<S>, testing_slot_clock: Option<TestingSlotClock>,
runtime: TestRuntime, runtime: TestRuntime,
log: Logger, log: Logger,
} }
impl<E: EthSpec, S: SlotClock> Builder<EphemeralHarnessType<E, S>, S> { impl<E: EthSpec> Builder<EphemeralHarnessType<E>> {
pub fn fresh_ephemeral_store(mut self) -> Self { pub fn fresh_ephemeral_store(mut self) -> Self {
let spec = self.spec.as_ref().expect("cannot build without spec"); let spec = self.spec.as_ref().expect("cannot build without spec");
let validator_keypairs = self let validator_keypairs = self
@ -247,7 +236,7 @@ impl<E: EthSpec, S: SlotClock> Builder<EphemeralHarnessType<E, S>, S> {
} }
} }
impl<E: EthSpec, S: SlotClock> Builder<DiskHarnessType<E, S>, S> { impl<E: EthSpec> Builder<DiskHarnessType<E>> {
/// Disk store, start from genesis. /// Disk store, start from genesis.
pub fn fresh_disk_store(mut self, store: Arc<HotColdDB<E, LevelDB<E>, LevelDB<E>>>) -> Self { pub fn fresh_disk_store(mut self, store: Arc<HotColdDB<E, LevelDB<E>, LevelDB<E>>>) -> Self {
let validator_keypairs = self let validator_keypairs = self
@ -284,24 +273,11 @@ impl<E: EthSpec, S: SlotClock> Builder<DiskHarnessType<E, S>, S> {
} }
} }
impl<E, Hot, Cold> Builder<TestingSlotClockHarnessType<E, Hot, Cold>, TestingSlotClock> impl<E, Hot, Cold> Builder<BaseHarnessType<E, Hot, Cold>>
where where
E: EthSpec, E: EthSpec,
Hot: ItemStore<E>, Hot: ItemStore<E>,
Cold: ItemStore<E>, Cold: ItemStore<E>,
{
pub fn testing_slot_clock(mut self, slot_clock: TestingSlotClock) -> Self {
self.testing_slot_clock = Some(slot_clock);
self
}
}
impl<E, Hot, Cold, S> Builder<BaseHarnessType<E, Hot, Cold, S>, S>
where
E: EthSpec,
Hot: ItemStore<E>,
Cold: ItemStore<E>,
S: SlotClock + 'static,
{ {
pub fn new(eth_spec_instance: E) -> Self { pub fn new(eth_spec_instance: E) -> Self {
let runtime = TestRuntime::default(); let runtime = TestRuntime::default();
@ -377,7 +353,7 @@ where
} }
/// This mutator will be run before the `store_mutator`. /// This mutator will be run before the `store_mutator`.
pub fn initial_mutator(mut self, mutator: BoxedMutator<E, Hot, Cold, S>) -> Self { pub fn initial_mutator(mut self, mutator: BoxedMutator<E, Hot, Cold>) -> Self {
assert!( assert!(
self.initial_mutator.is_none(), self.initial_mutator.is_none(),
"initial mutator already set" "initial mutator already set"
@ -387,14 +363,14 @@ where
} }
/// This mutator will be run after the `initial_mutator`. /// This mutator will be run after the `initial_mutator`.
pub fn store_mutator(mut self, mutator: BoxedMutator<E, Hot, Cold, S>) -> Self { pub fn store_mutator(mut self, mutator: BoxedMutator<E, Hot, Cold>) -> Self {
assert!(self.store_mutator.is_none(), "store mutator already set"); assert!(self.store_mutator.is_none(), "store mutator already set");
self.store_mutator = Some(mutator); self.store_mutator = Some(mutator);
self self
} }
/// Purposefully replace the `store_mutator`. /// Purposefully replace the `store_mutator`.
pub fn override_store_mutator(mut self, mutator: BoxedMutator<E, Hot, Cold, S>) -> Self { pub fn override_store_mutator(mut self, mutator: BoxedMutator<E, Hot, Cold>) -> Self {
assert!(self.store_mutator.is_some(), "store mutator not set"); assert!(self.store_mutator.is_some(), "store mutator not set");
self.store_mutator = Some(mutator); self.store_mutator = Some(mutator);
self self
@ -532,7 +508,12 @@ where
self self
} }
pub fn build(self) -> BeaconChainHarness<BaseHarnessType<E, Hot, Cold, S>> { pub fn testing_slot_clock(mut self, slot_clock: TestingSlotClock) -> Self {
self.testing_slot_clock = Some(slot_clock);
self
}
pub fn build(self) -> BeaconChainHarness<BaseHarnessType<E, Hot, Cold>> {
let (shutdown_tx, shutdown_receiver) = futures::channel::mpsc::channel(1); let (shutdown_tx, shutdown_receiver) = futures::channel::mpsc::channel(1);
let log = self.log; let log = self.log;
@ -636,369 +617,13 @@ pub type HarnessSyncContributions<E> = Vec<(
Option<SignedContributionAndProof<E>>, Option<SignedContributionAndProof<E>>,
)>; )>;
impl<E, Hot, Cold> BeaconChainHarness<TestingSlotClockHarnessType<E, Hot, Cold>> impl<E, Hot, Cold> BeaconChainHarness<BaseHarnessType<E, Hot, Cold>>
where where
E: EthSpec, E: EthSpec,
Hot: ItemStore<E>, Hot: ItemStore<E>,
Cold: ItemStore<E>, Cold: ItemStore<E>,
{ {
pub fn set_current_slot(&self, slot: Slot) { pub fn builder(eth_spec_instance: E) -> Builder<BaseHarnessType<E, Hot, Cold>> {
let current_slot = self.chain.slot().unwrap();
let current_epoch = current_slot.epoch(E::slots_per_epoch());
let epoch = slot.epoch(E::slots_per_epoch());
assert!(
epoch >= current_epoch,
"Jumping backwards to an earlier epoch isn't well defined. \
Please generate test blocks epoch-by-epoch instead."
);
self.chain.slot_clock.set_slot(slot.into());
}
pub async fn process_block(
&self,
slot: Slot,
block_root: Hash256,
block: SignedBeaconBlock<E>,
) -> Result<SignedBeaconBlockHash, BlockError<E>> {
self.set_current_slot(slot);
let block_hash: SignedBeaconBlockHash = self
.chain
.process_block(
block_root,
Arc::new(block),
CountUnrealized::True,
NotifyExecutionLayer::Yes,
)
.await?
.into();
self.chain.recompute_head_at_current_slot().await;
Ok(block_hash)
}
pub async fn add_block_at_slot(
&self,
slot: Slot,
state: BeaconState<E>,
) -> Result<(SignedBeaconBlockHash, SignedBeaconBlock<E>, BeaconState<E>), BlockError<E>> {
self.set_current_slot(slot);
let (block, new_state) = self.make_block(state, slot).await;
let block_hash = self
.process_block(slot, block.canonical_root(), block.clone())
.await?;
Ok((block_hash, block, new_state))
}
pub async fn add_attested_block_at_slot(
&self,
slot: Slot,
state: BeaconState<E>,
state_root: Hash256,
validators: &[usize],
) -> Result<(SignedBeaconBlockHash, BeaconState<E>), BlockError<E>> {
let (block_hash, block, state) = self.add_block_at_slot(slot, state).await?;
self.attest_block(&state, state_root, block_hash, &block, validators);
Ok((block_hash, state))
}
async fn add_attested_blocks_at_slots_given_lbh(
&self,
mut state: BeaconState<E>,
state_root: Hash256,
slots: &[Slot],
validators: &[usize],
mut latest_block_hash: Option<SignedBeaconBlockHash>,
) -> AddBlocksResult<E> {
assert!(
slots.windows(2).all(|w| w[0] <= w[1]),
"Slots have to be sorted"
); // slice.is_sorted() isn't stabilized at the moment of writing this
let mut block_hash_from_slot: HashMap<Slot, SignedBeaconBlockHash> = HashMap::new();
let mut state_hash_from_slot: HashMap<Slot, BeaconStateHash> = HashMap::new();
for slot in slots {
let (block_hash, new_state) = self
.add_attested_block_at_slot(*slot, state, state_root, validators)
.await
.unwrap();
state = new_state;
block_hash_from_slot.insert(*slot, block_hash);
state_hash_from_slot.insert(*slot, state.tree_hash_root().into());
latest_block_hash = Some(block_hash);
}
(
block_hash_from_slot,
state_hash_from_slot,
latest_block_hash.unwrap(),
state,
)
}
pub async fn add_attested_blocks_at_slots(
&self,
state: BeaconState<E>,
state_root: Hash256,
slots: &[Slot],
validators: &[usize],
) -> AddBlocksResult<E> {
assert!(!slots.is_empty());
self.add_attested_blocks_at_slots_given_lbh(state, state_root, slots, validators, None)
.await
}
/// A monstrosity of great usefulness.
///
/// Calls `add_attested_blocks_at_slots` for each of the chains in `chains`,
/// taking care to batch blocks by epoch so that the slot clock gets advanced one
/// epoch at a time.
///
/// Chains is a vec of `(state, slots, validators)` tuples.
pub async fn add_blocks_on_multiple_chains(
&self,
chains: Vec<(BeaconState<E>, Vec<Slot>, Vec<usize>)>,
) -> Vec<AddBlocksResult<E>> {
let slots_per_epoch = E::slots_per_epoch();
let min_epoch = chains
.iter()
.map(|(_, slots, _)| slots.iter().min().unwrap())
.min()
.unwrap()
.epoch(slots_per_epoch);
let max_epoch = chains
.iter()
.map(|(_, slots, _)| slots.iter().max().unwrap())
.max()
.unwrap()
.epoch(slots_per_epoch);
let mut chains = chains
.into_iter()
.map(|(state, slots, validators)| {
(
state,
slots,
validators,
HashMap::new(),
HashMap::new(),
SignedBeaconBlockHash::from(Hash256::zero()),
)
})
.collect::<Vec<_>>();
for epoch in min_epoch.as_u64()..=max_epoch.as_u64() {
let mut new_chains = vec![];
for (
mut head_state,
slots,
validators,
mut block_hashes,
mut state_hashes,
head_block,
) in chains
{
let epoch_slots = slots
.iter()
.filter(|s| s.epoch(slots_per_epoch).as_u64() == epoch)
.copied()
.collect::<Vec<_>>();
let head_state_root = head_state.update_tree_hash_cache().unwrap();
let (new_block_hashes, new_state_hashes, new_head_block, new_head_state) = self
.add_attested_blocks_at_slots_given_lbh(
head_state,
head_state_root,
&epoch_slots,
&validators,
Some(head_block),
)
.await;
block_hashes.extend(new_block_hashes);
state_hashes.extend(new_state_hashes);
new_chains.push((
new_head_state,
slots,
validators,
block_hashes,
state_hashes,
new_head_block,
));
}
chains = new_chains;
}
chains
.into_iter()
.map(|(state, _, _, block_hashes, state_hashes, head_block)| {
(block_hashes, state_hashes, head_block, state)
})
.collect()
}
/// Deprecated: Do not modify the slot clock manually; rely on add_attested_blocks_at_slots()
/// instead
///
/// Advance the slot of the `BeaconChain`.
///
/// Does not produce blocks or attestations.
pub fn advance_slot(&self) {
self.chain.slot_clock.advance_slot();
}
/// Advance the clock to `lookahead` before the start of `slot`.
pub fn advance_to_slot_lookahead(&self, slot: Slot, lookahead: Duration) {
let time = self.chain.slot_clock.start_of(slot).unwrap() - lookahead;
self.chain.slot_clock.set_current_time(time);
}
/// Uses `Self::extend_chain` to build the chain out to the `target_slot`.
pub async fn extend_to_slot(&self, target_slot: Slot) -> Hash256 {
if self.chain.slot().unwrap() == self.chain.canonical_head.cached_head().head_slot() {
self.advance_slot();
}
let num_slots = target_slot
.as_usize()
.checked_sub(self.chain.slot().unwrap().as_usize())
.expect("target_slot must be >= current_slot")
.checked_add(1)
.unwrap();
self.extend_slots(num_slots).await
}
/// Uses `Self::extend_chain` to `num_slots` blocks.
///
/// Utilizes:
///
/// - BlockStrategy::OnCanonicalHead,
/// - AttestationStrategy::AllValidators,
pub async fn extend_slots(&self, num_slots: usize) -> Hash256 {
if self.chain.slot().unwrap() == self.chain.canonical_head.cached_head().head_slot() {
self.advance_slot();
}
self.extend_chain(
num_slots,
BlockStrategy::OnCanonicalHead,
AttestationStrategy::AllValidators,
)
.await
}
/// Deprecated: Use add_attested_blocks_at_slots() instead
///
/// Extend the `BeaconChain` with some blocks and attestations. Returns the root of the
/// last-produced block (the head of the chain).
///
/// Chain will be extended by `num_blocks` blocks.
///
/// The `block_strategy` dictates where the new blocks will be placed.
///
/// The `attestation_strategy` dictates which validators will attest to the newly created
/// blocks.
pub async fn extend_chain(
&self,
num_blocks: usize,
block_strategy: BlockStrategy,
attestation_strategy: AttestationStrategy,
) -> Hash256 {
let (mut state, slots) = match block_strategy {
BlockStrategy::OnCanonicalHead => {
let current_slot: u64 = self.get_current_slot().into();
let slots: Vec<Slot> = (current_slot..(current_slot + (num_blocks as u64)))
.map(Slot::new)
.collect();
let state = self.get_current_state();
(state, slots)
}
BlockStrategy::ForkCanonicalChainAt {
previous_slot,
first_slot,
} => {
let first_slot_: u64 = first_slot.into();
let slots: Vec<Slot> = (first_slot_..(first_slot_ + (num_blocks as u64)))
.map(Slot::new)
.collect();
let state = self
.chain
.state_at_slot(previous_slot, StateSkipConfig::WithStateRoots)
.unwrap();
(state, slots)
}
};
let validators = match attestation_strategy {
AttestationStrategy::AllValidators => self.get_all_validators(),
AttestationStrategy::SomeValidators(vals) => vals,
};
let state_root = state.update_tree_hash_cache().unwrap();
let (_, _, last_produced_block_hash, _) = self
.add_attested_blocks_at_slots(state, state_root, &slots, &validators)
.await;
last_produced_block_hash.into()
}
/// Deprecated: Use add_attested_blocks_at_slots() instead
///
/// Creates two forks:
///
/// - The "honest" fork: created by the `honest_validators` who have built `honest_fork_blocks`
/// on the head
/// - The "faulty" fork: created by the `faulty_validators` who skipped a slot and
/// then built `faulty_fork_blocks`.
///
/// Returns `(honest_head, faulty_head)`, the roots of the blocks at the top of each chain.
pub async fn generate_two_forks_by_skipping_a_block(
&self,
honest_validators: &[usize],
faulty_validators: &[usize],
honest_fork_blocks: usize,
faulty_fork_blocks: usize,
) -> (Hash256, Hash256) {
let initial_head_slot = self.chain.head_snapshot().beacon_block.slot();
// Move to the next slot so we may produce some more blocks on the head.
self.advance_slot();
// Extend the chain with blocks where only honest validators agree.
let honest_head = self
.extend_chain(
honest_fork_blocks,
BlockStrategy::OnCanonicalHead,
AttestationStrategy::SomeValidators(honest_validators.to_vec()),
)
.await;
// Go back to the last block where all agreed, and build blocks upon it where only faulty nodes
// agree.
let faulty_head = self
.extend_chain(
faulty_fork_blocks,
BlockStrategy::ForkCanonicalChainAt {
previous_slot: initial_head_slot,
// `initial_head_slot + 2` means one slot is skipped.
first_slot: initial_head_slot + 2,
},
AttestationStrategy::SomeValidators(faulty_validators.to_vec()),
)
.await;
assert_ne!(honest_head, faulty_head, "forks should be distinct");
(honest_head, faulty_head)
}
}
impl<E, Hot, Cold, S> BeaconChainHarness<BaseHarnessType<E, Hot, Cold, S>>
where
E: EthSpec,
Hot: ItemStore<E>,
Cold: ItemStore<E>,
S: SlotClock + 'static,
{
pub fn builder(eth_spec_instance: E) -> Builder<BaseHarnessType<E, Hot, Cold, S>, S> {
Builder::new(eth_spec_instance) Builder::new(eth_spec_instance)
} }
@ -1064,16 +689,6 @@ where
self.chain.canonical_head.cached_head().head_block_root() self.chain.canonical_head.cached_head().head_block_root()
} }
pub fn get_finalized_checkpoints(&self) -> HashSet<SignedBeaconBlockHash> {
let chain_dump = self.chain.chain_dump().unwrap();
chain_dump
.iter()
.cloned()
.map(|checkpoint| checkpoint.beacon_state.finalized_checkpoint().root.into())
.filter(|block_hash| *block_hash != Hash256::zero().into())
.collect()
}
pub fn finalized_checkpoint(&self) -> Checkpoint { pub fn finalized_checkpoint(&self) -> Checkpoint {
self.chain self.chain
.canonical_head .canonical_head
@ -1129,18 +744,6 @@ where
state.get_block_root(slot).unwrap() == state.get_block_root(slot - 1).unwrap() state.get_block_root(slot).unwrap() == state.get_block_root(slot - 1).unwrap()
} }
/// Deprecated: Use make_block() instead
///
/// Returns a newly created block, signed by the proposer for the given slot.
pub async fn build_block(
&self,
state: BeaconState<E>,
slot: Slot,
_block_strategy: BlockStrategy,
) -> (SignedBeaconBlock<E>, BeaconState<E>) {
self.make_block(state, slot).await
}
pub async fn make_block( pub async fn make_block(
&self, &self,
mut state: BeaconState<E>, mut state: BeaconState<E>,
@ -2053,6 +1656,27 @@ where
(deposits, state) (deposits, state)
} }
pub async fn process_block(
&self,
slot: Slot,
block_root: Hash256,
block: SignedBeaconBlock<E>,
) -> Result<SignedBeaconBlockHash, BlockError<E>> {
self.set_current_slot(slot);
let block_hash: SignedBeaconBlockHash = self
.chain
.process_block(
block_root,
Arc::new(block),
CountUnrealized::True,
NotifyExecutionLayer::Yes,
)
.await?
.into();
self.chain.recompute_head_at_current_slot().await;
Ok(block_hash)
}
pub async fn process_block_result( pub async fn process_block_result(
&self, &self,
block: SignedBeaconBlock<E>, block: SignedBeaconBlock<E>,
@ -2110,6 +1734,31 @@ where
} }
} }
pub fn set_current_slot(&self, slot: Slot) {
let current_slot = self.chain.slot().unwrap();
let current_epoch = current_slot.epoch(E::slots_per_epoch());
let epoch = slot.epoch(E::slots_per_epoch());
assert!(
epoch >= current_epoch,
"Jumping backwards to an earlier epoch isn't well defined. \
Please generate test blocks epoch-by-epoch instead."
);
self.chain.slot_clock.set_slot(slot.into());
}
pub async fn add_block_at_slot(
&self,
slot: Slot,
state: BeaconState<E>,
) -> Result<(SignedBeaconBlockHash, SignedBeaconBlock<E>, BeaconState<E>), BlockError<E>> {
self.set_current_slot(slot);
let (block, new_state) = self.make_block(state, slot).await;
let block_hash = self
.process_block(slot, block.canonical_root(), block.clone())
.await?;
Ok((block_hash, block, new_state))
}
pub fn attest_block( pub fn attest_block(
&self, &self,
state: &BeaconState<E>, state: &BeaconState<E>,
@ -2123,6 +1772,330 @@ where
self.process_attestations(attestations); self.process_attestations(attestations);
} }
pub async fn add_attested_block_at_slot(
&self,
slot: Slot,
state: BeaconState<E>,
state_root: Hash256,
validators: &[usize],
) -> Result<(SignedBeaconBlockHash, BeaconState<E>), BlockError<E>> {
let (block_hash, block, state) = self.add_block_at_slot(slot, state).await?;
self.attest_block(&state, state_root, block_hash, &block, validators);
Ok((block_hash, state))
}
pub async fn add_attested_blocks_at_slots(
&self,
state: BeaconState<E>,
state_root: Hash256,
slots: &[Slot],
validators: &[usize],
) -> AddBlocksResult<E> {
assert!(!slots.is_empty());
self.add_attested_blocks_at_slots_given_lbh(state, state_root, slots, validators, None)
.await
}
async fn add_attested_blocks_at_slots_given_lbh(
&self,
mut state: BeaconState<E>,
state_root: Hash256,
slots: &[Slot],
validators: &[usize],
mut latest_block_hash: Option<SignedBeaconBlockHash>,
) -> AddBlocksResult<E> {
assert!(
slots.windows(2).all(|w| w[0] <= w[1]),
"Slots have to be sorted"
); // slice.is_sorted() isn't stabilized at the moment of writing this
let mut block_hash_from_slot: HashMap<Slot, SignedBeaconBlockHash> = HashMap::new();
let mut state_hash_from_slot: HashMap<Slot, BeaconStateHash> = HashMap::new();
for slot in slots {
let (block_hash, new_state) = self
.add_attested_block_at_slot(*slot, state, state_root, validators)
.await
.unwrap();
state = new_state;
block_hash_from_slot.insert(*slot, block_hash);
state_hash_from_slot.insert(*slot, state.tree_hash_root().into());
latest_block_hash = Some(block_hash);
}
(
block_hash_from_slot,
state_hash_from_slot,
latest_block_hash.unwrap(),
state,
)
}
/// A monstrosity of great usefulness.
///
/// Calls `add_attested_blocks_at_slots` for each of the chains in `chains`,
/// taking care to batch blocks by epoch so that the slot clock gets advanced one
/// epoch at a time.
///
/// Chains is a vec of `(state, slots, validators)` tuples.
pub async fn add_blocks_on_multiple_chains(
&self,
chains: Vec<(BeaconState<E>, Vec<Slot>, Vec<usize>)>,
) -> Vec<AddBlocksResult<E>> {
let slots_per_epoch = E::slots_per_epoch();
let min_epoch = chains
.iter()
.map(|(_, slots, _)| slots.iter().min().unwrap())
.min()
.unwrap()
.epoch(slots_per_epoch);
let max_epoch = chains
.iter()
.map(|(_, slots, _)| slots.iter().max().unwrap())
.max()
.unwrap()
.epoch(slots_per_epoch);
let mut chains = chains
.into_iter()
.map(|(state, slots, validators)| {
(
state,
slots,
validators,
HashMap::new(),
HashMap::new(),
SignedBeaconBlockHash::from(Hash256::zero()),
)
})
.collect::<Vec<_>>();
for epoch in min_epoch.as_u64()..=max_epoch.as_u64() {
let mut new_chains = vec![];
for (
mut head_state,
slots,
validators,
mut block_hashes,
mut state_hashes,
head_block,
) in chains
{
let epoch_slots = slots
.iter()
.filter(|s| s.epoch(slots_per_epoch).as_u64() == epoch)
.copied()
.collect::<Vec<_>>();
let head_state_root = head_state.update_tree_hash_cache().unwrap();
let (new_block_hashes, new_state_hashes, new_head_block, new_head_state) = self
.add_attested_blocks_at_slots_given_lbh(
head_state,
head_state_root,
&epoch_slots,
&validators,
Some(head_block),
)
.await;
block_hashes.extend(new_block_hashes);
state_hashes.extend(new_state_hashes);
new_chains.push((
new_head_state,
slots,
validators,
block_hashes,
state_hashes,
new_head_block,
));
}
chains = new_chains;
}
chains
.into_iter()
.map(|(state, _, _, block_hashes, state_hashes, head_block)| {
(block_hashes, state_hashes, head_block, state)
})
.collect()
}
pub fn get_finalized_checkpoints(&self) -> HashSet<SignedBeaconBlockHash> {
let chain_dump = self.chain.chain_dump().unwrap();
chain_dump
.iter()
.cloned()
.map(|checkpoint| checkpoint.beacon_state.finalized_checkpoint().root.into())
.filter(|block_hash| *block_hash != Hash256::zero().into())
.collect()
}
/// Deprecated: Do not modify the slot clock manually; rely on add_attested_blocks_at_slots()
/// instead
///
/// Advance the slot of the `BeaconChain`.
///
/// Does not produce blocks or attestations.
pub fn advance_slot(&self) {
self.chain.slot_clock.advance_slot();
}
/// Advance the clock to `lookahead` before the start of `slot`.
pub fn advance_to_slot_lookahead(&self, slot: Slot, lookahead: Duration) {
let time = self.chain.slot_clock.start_of(slot).unwrap() - lookahead;
self.chain.slot_clock.set_current_time(time);
}
/// Deprecated: Use make_block() instead
///
/// Returns a newly created block, signed by the proposer for the given slot.
pub async fn build_block(
&self,
state: BeaconState<E>,
slot: Slot,
_block_strategy: BlockStrategy,
) -> (SignedBeaconBlock<E>, BeaconState<E>) {
self.make_block(state, slot).await
}
/// Uses `Self::extend_chain` to build the chain out to the `target_slot`.
pub async fn extend_to_slot(&self, target_slot: Slot) -> Hash256 {
if self.chain.slot().unwrap() == self.chain.canonical_head.cached_head().head_slot() {
self.advance_slot();
}
let num_slots = target_slot
.as_usize()
.checked_sub(self.chain.slot().unwrap().as_usize())
.expect("target_slot must be >= current_slot")
.checked_add(1)
.unwrap();
self.extend_slots(num_slots).await
}
/// Uses `Self::extend_chain` to `num_slots` blocks.
///
/// Utilizes:
///
/// - BlockStrategy::OnCanonicalHead,
/// - AttestationStrategy::AllValidators,
pub async fn extend_slots(&self, num_slots: usize) -> Hash256 {
if self.chain.slot().unwrap() == self.chain.canonical_head.cached_head().head_slot() {
self.advance_slot();
}
self.extend_chain(
num_slots,
BlockStrategy::OnCanonicalHead,
AttestationStrategy::AllValidators,
)
.await
}
/// Deprecated: Use add_attested_blocks_at_slots() instead
///
/// Extend the `BeaconChain` with some blocks and attestations. Returns the root of the
/// last-produced block (the head of the chain).
///
/// Chain will be extended by `num_blocks` blocks.
///
/// The `block_strategy` dictates where the new blocks will be placed.
///
/// The `attestation_strategy` dictates which validators will attest to the newly created
/// blocks.
pub async fn extend_chain(
&self,
num_blocks: usize,
block_strategy: BlockStrategy,
attestation_strategy: AttestationStrategy,
) -> Hash256 {
let (mut state, slots) = match block_strategy {
BlockStrategy::OnCanonicalHead => {
let current_slot: u64 = self.get_current_slot().into();
let slots: Vec<Slot> = (current_slot..(current_slot + (num_blocks as u64)))
.map(Slot::new)
.collect();
let state = self.get_current_state();
(state, slots)
}
BlockStrategy::ForkCanonicalChainAt {
previous_slot,
first_slot,
} => {
let first_slot_: u64 = first_slot.into();
let slots: Vec<Slot> = (first_slot_..(first_slot_ + (num_blocks as u64)))
.map(Slot::new)
.collect();
let state = self
.chain
.state_at_slot(previous_slot, StateSkipConfig::WithStateRoots)
.unwrap();
(state, slots)
}
};
let validators = match attestation_strategy {
AttestationStrategy::AllValidators => self.get_all_validators(),
AttestationStrategy::SomeValidators(vals) => vals,
};
let state_root = state.update_tree_hash_cache().unwrap();
let (_, _, last_produced_block_hash, _) = self
.add_attested_blocks_at_slots(state, state_root, &slots, &validators)
.await;
last_produced_block_hash.into()
}
/// Deprecated: Use add_attested_blocks_at_slots() instead
///
/// Creates two forks:
///
/// - The "honest" fork: created by the `honest_validators` who have built `honest_fork_blocks`
/// on the head
/// - The "faulty" fork: created by the `faulty_validators` who skipped a slot and
/// then built `faulty_fork_blocks`.
///
/// Returns `(honest_head, faulty_head)`, the roots of the blocks at the top of each chain.
pub async fn generate_two_forks_by_skipping_a_block(
&self,
honest_validators: &[usize],
faulty_validators: &[usize],
honest_fork_blocks: usize,
faulty_fork_blocks: usize,
) -> (Hash256, Hash256) {
let initial_head_slot = self.chain.head_snapshot().beacon_block.slot();
// Move to the next slot so we may produce some more blocks on the head.
self.advance_slot();
// Extend the chain with blocks where only honest validators agree.
let honest_head = self
.extend_chain(
honest_fork_blocks,
BlockStrategy::OnCanonicalHead,
AttestationStrategy::SomeValidators(honest_validators.to_vec()),
)
.await;
// Go back to the last block where all agreed, and build blocks upon it where only faulty nodes
// agree.
let faulty_head = self
.extend_chain(
faulty_fork_blocks,
BlockStrategy::ForkCanonicalChainAt {
previous_slot: initial_head_slot,
// `initial_head_slot + 2` means one slot is skipped.
first_slot: initial_head_slot + 2,
},
AttestationStrategy::SomeValidators(faulty_validators.to_vec()),
)
.await;
assert_ne!(honest_head, faulty_head, "forks should be distinct");
(honest_head, faulty_head)
}
pub fn process_sync_contributions( pub fn process_sync_contributions(
&self, &self,
sync_contributions: HarnessSyncContributions<E>, sync_contributions: HarnessSyncContributions<E>,

View File

@ -191,14 +191,14 @@ impl DatabasePubkey {
#[cfg(test)] #[cfg(test)]
mod test { mod test {
use super::*; use super::*;
use crate::test_utils::{BeaconChainHarness, EphemeralTestingSlotClockHarnessType}; use crate::test_utils::{BeaconChainHarness, EphemeralHarnessType};
use logging::test_logger; use logging::test_logger;
use std::sync::Arc; use std::sync::Arc;
use store::HotColdDB; use store::HotColdDB;
use types::{BeaconState, EthSpec, Keypair, MainnetEthSpec}; use types::{BeaconState, EthSpec, Keypair, MainnetEthSpec};
type E = MainnetEthSpec; type E = MainnetEthSpec;
type T = EphemeralTestingSlotClockHarnessType<E>; type T = EphemeralHarnessType<E>;
fn get_state(validator_count: usize) -> (BeaconState<E>, Vec<Keypair>) { fn get_state(validator_count: usize) -> (BeaconState<E>, Vec<Keypair>) {
let harness = BeaconChainHarness::builder(MainnetEthSpec) let harness = BeaconChainHarness::builder(MainnetEthSpec)

View File

@ -3,8 +3,7 @@
use beacon_chain::{ use beacon_chain::{
attestation_verification::Error as AttnError, attestation_verification::Error as AttnError,
test_utils::{ test_utils::{
test_spec, AttestationStrategy, BeaconChainHarness, BlockStrategy, test_spec, AttestationStrategy, BeaconChainHarness, BlockStrategy, EphemeralHarnessType,
EphemeralTestingSlotClockHarnessType,
}, },
BeaconChain, BeaconChainError, BeaconChainTypes, WhenSlotSkipped, BeaconChain, BeaconChainError, BeaconChainTypes, WhenSlotSkipped,
}; };
@ -32,9 +31,7 @@ lazy_static! {
} }
/// Returns a beacon chain harness. /// Returns a beacon chain harness.
fn get_harness( fn get_harness(validator_count: usize) -> BeaconChainHarness<EphemeralHarnessType<E>> {
validator_count: usize,
) -> BeaconChainHarness<EphemeralTestingSlotClockHarnessType<E>> {
let mut spec = test_spec::<E>(); let mut spec = test_spec::<E>();
// A kind-of arbitrary number that ensures that _some_ validators are aggregators, but // A kind-of arbitrary number that ensures that _some_ validators are aggregators, but
@ -192,7 +189,7 @@ fn get_non_aggregator<T: BeaconChainTypes>(
} }
struct GossipTester { struct GossipTester {
harness: BeaconChainHarness<EphemeralTestingSlotClockHarnessType<E>>, harness: BeaconChainHarness<EphemeralHarnessType<E>>,
/* /*
* Valid unaggregated attestation * Valid unaggregated attestation
*/ */

View File

@ -2,10 +2,7 @@
use beacon_chain::{ use beacon_chain::{
blob_verification::{AsBlock, BlockWrapper}, blob_verification::{AsBlock, BlockWrapper},
test_utils::{ test_utils::{AttestationStrategy, BeaconChainHarness, BlockStrategy, EphemeralHarnessType},
AttestationStrategy, BeaconChainHarness, BlockStrategy,
EphemeralTestingSlotClockHarnessType,
},
}; };
use beacon_chain::{BeaconSnapshot, BlockError, ChainSegmentResult, NotifyExecutionLayer}; use beacon_chain::{BeaconSnapshot, BlockError, ChainSegmentResult, NotifyExecutionLayer};
use fork_choice::CountUnrealized; use fork_choice::CountUnrealized;
@ -68,9 +65,7 @@ async fn get_chain_segment() -> Vec<BeaconSnapshot<E>> {
segment segment
} }
fn get_harness( fn get_harness(validator_count: usize) -> BeaconChainHarness<EphemeralHarnessType<E>> {
validator_count: usize,
) -> BeaconChainHarness<EphemeralTestingSlotClockHarnessType<E>> {
let harness = BeaconChainHarness::builder(MainnetEthSpec) let harness = BeaconChainHarness::builder(MainnetEthSpec)
.default_spec() .default_spec()
.keypairs(KEYPAIRS[0..validator_count].to_vec()) .keypairs(KEYPAIRS[0..validator_count].to_vec())
@ -104,7 +99,7 @@ fn junk_aggregate_signature() -> AggregateSignature {
fn update_proposal_signatures( fn update_proposal_signatures(
snapshots: &mut [BeaconSnapshot<E>], snapshots: &mut [BeaconSnapshot<E>],
harness: &BeaconChainHarness<EphemeralTestingSlotClockHarnessType<E>>, harness: &BeaconChainHarness<EphemeralHarnessType<E>>,
) { ) {
for snapshot in snapshots { for snapshot in snapshots {
let spec = &harness.chain.spec; let spec = &harness.chain.spec;
@ -335,7 +330,7 @@ async fn chain_segment_non_linear_slots() {
async fn assert_invalid_signature( async fn assert_invalid_signature(
chain_segment: &[BeaconSnapshot<E>], chain_segment: &[BeaconSnapshot<E>],
harness: &BeaconChainHarness<EphemeralTestingSlotClockHarnessType<E>>, harness: &BeaconChainHarness<EphemeralHarnessType<E>>,
block_index: usize, block_index: usize,
snapshots: &[BeaconSnapshot<E>], snapshots: &[BeaconSnapshot<E>],
item: &str, item: &str,
@ -406,7 +401,7 @@ async fn assert_invalid_signature(
async fn get_invalid_sigs_harness( async fn get_invalid_sigs_harness(
chain_segment: &[BeaconSnapshot<E>], chain_segment: &[BeaconSnapshot<E>],
) -> BeaconChainHarness<EphemeralTestingSlotClockHarnessType<E>> { ) -> BeaconChainHarness<EphemeralHarnessType<E>> {
let harness = get_harness(VALIDATOR_COUNT); let harness = get_harness(VALIDATOR_COUNT);
harness harness
.chain .chain

View File

@ -6,7 +6,7 @@ use beacon_chain::otb_verification_service::{
}; };
use beacon_chain::{ use beacon_chain::{
canonical_head::{CachedHead, CanonicalHead}, canonical_head::{CachedHead, CanonicalHead},
test_utils::{BeaconChainHarness, EphemeralTestingSlotClockHarnessType}, test_utils::{BeaconChainHarness, EphemeralHarnessType},
BeaconChainError, BlockError, ExecutionPayloadError, NotifyExecutionLayer, BeaconChainError, BlockError, ExecutionPayloadError, NotifyExecutionLayer,
OverrideForkchoiceUpdate, StateSkipConfig, WhenSlotSkipped, OverrideForkchoiceUpdate, StateSkipConfig, WhenSlotSkipped,
INVALID_FINALIZED_MERGE_TRANSITION_BLOCK_SHUTDOWN_REASON, INVALID_FINALIZED_MERGE_TRANSITION_BLOCK_SHUTDOWN_REASON,
@ -45,7 +45,7 @@ enum Payload {
} }
struct InvalidPayloadRig { struct InvalidPayloadRig {
harness: BeaconChainHarness<EphemeralTestingSlotClockHarnessType<E>>, harness: BeaconChainHarness<EphemeralHarnessType<E>>,
enable_attestations: bool, enable_attestations: bool,
} }
@ -116,7 +116,7 @@ impl InvalidPayloadRig {
self.harness.chain.canonical_head.cached_head() self.harness.chain.canonical_head.cached_head()
} }
fn canonical_head(&self) -> &CanonicalHead<EphemeralTestingSlotClockHarnessType<E>> { fn canonical_head(&self) -> &CanonicalHead<EphemeralHarnessType<E>> {
&self.harness.chain.canonical_head &self.harness.chain.canonical_head
} }

View File

@ -3,8 +3,7 @@
use std::collections::HashMap; use std::collections::HashMap;
use beacon_chain::test_utils::{ use beacon_chain::test_utils::{
generate_deterministic_keypairs, BeaconChainHarness, generate_deterministic_keypairs, BeaconChainHarness, EphemeralHarnessType,
EphemeralTestingSlotClockHarnessType as HarnessType,
}; };
use beacon_chain::{ use beacon_chain::{
test_utils::{AttestationStrategy, BlockStrategy, RelativeSyncCommittee}, test_utils::{AttestationStrategy, BlockStrategy, RelativeSyncCommittee},
@ -18,7 +17,7 @@ lazy_static! {
static ref KEYPAIRS: Vec<Keypair> = generate_deterministic_keypairs(VALIDATOR_COUNT); static ref KEYPAIRS: Vec<Keypair> = generate_deterministic_keypairs(VALIDATOR_COUNT);
} }
fn get_harness<E: EthSpec>() -> BeaconChainHarness<HarnessType<E>> { fn get_harness<E: EthSpec>() -> BeaconChainHarness<EphemeralHarnessType<E>> {
let mut spec = E::default_spec(); let mut spec = E::default_spec();
spec.altair_fork_epoch = Some(Epoch::new(0)); // We use altair for all tests spec.altair_fork_epoch = Some(Epoch::new(0)); // We use altair for all tests

View File

@ -1,9 +1,7 @@
#![cfg(not(debug_assertions))] #![cfg(not(debug_assertions))]
use beacon_chain::sync_committee_verification::Error as SyncCommitteeError; use beacon_chain::sync_committee_verification::Error as SyncCommitteeError;
use beacon_chain::test_utils::{ use beacon_chain::test_utils::{BeaconChainHarness, EphemeralHarnessType, RelativeSyncCommittee};
BeaconChainHarness, EphemeralTestingSlotClockHarnessType, RelativeSyncCommittee,
};
use int_to_bytes::int_to_bytes32; use int_to_bytes::int_to_bytes32;
use lazy_static::lazy_static; use lazy_static::lazy_static;
use safe_arith::SafeArith; use safe_arith::SafeArith;
@ -25,9 +23,7 @@ lazy_static! {
} }
/// Returns a beacon chain harness. /// Returns a beacon chain harness.
fn get_harness( fn get_harness(validator_count: usize) -> BeaconChainHarness<EphemeralHarnessType<E>> {
validator_count: usize,
) -> BeaconChainHarness<EphemeralTestingSlotClockHarnessType<E>> {
let mut spec = E::default_spec(); let mut spec = E::default_spec();
spec.altair_fork_epoch = Some(Epoch::new(0)); spec.altair_fork_epoch = Some(Epoch::new(0));
let harness = BeaconChainHarness::builder(MainnetEthSpec) let harness = BeaconChainHarness::builder(MainnetEthSpec)
@ -46,7 +42,7 @@ fn get_harness(
/// ///
/// Also returns some info about who created it. /// Also returns some info about who created it.
fn get_valid_sync_committee_message( fn get_valid_sync_committee_message(
harness: &BeaconChainHarness<EphemeralTestingSlotClockHarnessType<E>>, harness: &BeaconChainHarness<EphemeralHarnessType<E>>,
slot: Slot, slot: Slot,
relative_sync_committee: RelativeSyncCommittee, relative_sync_committee: RelativeSyncCommittee,
message_index: usize, message_index: usize,
@ -72,7 +68,7 @@ fn get_valid_sync_committee_message(
} }
fn get_valid_sync_contribution( fn get_valid_sync_contribution(
harness: &BeaconChainHarness<EphemeralTestingSlotClockHarnessType<E>>, harness: &BeaconChainHarness<EphemeralHarnessType<E>>,
relative_sync_committee: RelativeSyncCommittee, relative_sync_committee: RelativeSyncCommittee,
) -> (SignedContributionAndProof<E>, usize, SecretKey) { ) -> (SignedContributionAndProof<E>, usize, SecretKey) {
let head_state = harness.chain.head_beacon_state_cloned(); let head_state = harness.chain.head_beacon_state_cloned();
@ -104,7 +100,7 @@ fn get_valid_sync_contribution(
/// Returns a proof and index for a validator that is **not** an aggregator for the current sync period. /// Returns a proof and index for a validator that is **not** an aggregator for the current sync period.
fn get_non_aggregator( fn get_non_aggregator(
harness: &BeaconChainHarness<EphemeralTestingSlotClockHarnessType<E>>, harness: &BeaconChainHarness<EphemeralHarnessType<E>>,
slot: Slot, slot: Slot,
) -> (usize, SecretKey) { ) -> (usize, SecretKey) {
let state = &harness.chain.head_snapshot().beacon_state; let state = &harness.chain.head_snapshot().beacon_state;

View File

@ -3,8 +3,8 @@
use beacon_chain::{ use beacon_chain::{
attestation_verification::Error as AttnError, attestation_verification::Error as AttnError,
test_utils::{ test_utils::{
AttestationStrategy, BeaconChainHarness, BlockStrategy, AttestationStrategy, BeaconChainHarness, BlockStrategy, EphemeralHarnessType,
EphemeralTestingSlotClockHarnessType, OP_POOL_DB_KEY, OP_POOL_DB_KEY,
}, },
BeaconChain, NotifyExecutionLayer, StateSkipConfig, WhenSlotSkipped, BeaconChain, NotifyExecutionLayer, StateSkipConfig, WhenSlotSkipped,
}; };
@ -26,9 +26,7 @@ lazy_static! {
static ref KEYPAIRS: Vec<Keypair> = types::test_utils::generate_deterministic_keypairs(VALIDATOR_COUNT); static ref KEYPAIRS: Vec<Keypair> = types::test_utils::generate_deterministic_keypairs(VALIDATOR_COUNT);
} }
fn get_harness( fn get_harness(validator_count: usize) -> BeaconChainHarness<EphemeralHarnessType<MinimalEthSpec>> {
validator_count: usize,
) -> BeaconChainHarness<EphemeralTestingSlotClockHarnessType<MinimalEthSpec>> {
let harness = BeaconChainHarness::builder(MinimalEthSpec) let harness = BeaconChainHarness::builder(MinimalEthSpec)
.default_spec() .default_spec()
.keypairs(KEYPAIRS[0..validator_count].to_vec()) .keypairs(KEYPAIRS[0..validator_count].to_vec())
@ -145,7 +143,7 @@ async fn iterators() {
} }
fn find_reorg_slot( fn find_reorg_slot(
chain: &BeaconChain<EphemeralTestingSlotClockHarnessType<MinimalEthSpec>>, chain: &BeaconChain<EphemeralHarnessType<MinimalEthSpec>>,
new_state: &BeaconState<MinimalEthSpec>, new_state: &BeaconState<MinimalEthSpec>,
new_block_root: Hash256, new_block_root: Hash256,
) -> Slot { ) -> Slot {

View File

@ -153,9 +153,7 @@ pub async fn broadcast_address_changes<T: BeaconChainTypes>(
#[cfg(test)] #[cfg(test)]
mod tests { mod tests {
use super::*; use super::*;
use beacon_chain::test_utils::{ use beacon_chain::test_utils::{BeaconChainHarness, EphemeralHarnessType};
BeaconChainHarness, EphemeralTestingSlotClockHarnessType as HarnessType,
};
use operation_pool::ReceivedPreCapella; use operation_pool::ReceivedPreCapella;
use state_processing::{SigVerifiedOp, VerifyOperation}; use state_processing::{SigVerifiedOp, VerifyOperation};
use std::collections::HashSet; use std::collections::HashSet;
@ -168,7 +166,7 @@ mod tests {
pub const EXECUTION_ADDRESS: Address = Address::repeat_byte(42); pub const EXECUTION_ADDRESS: Address = Address::repeat_byte(42);
struct Tester { struct Tester {
harness: BeaconChainHarness<HarnessType<E>>, harness: BeaconChainHarness<EphemeralHarnessType<E>>,
/// Changes which should be broadcast at the Capella fork. /// Changes which should be broadcast at the Capella fork.
received_pre_capella_changes: Vec<SigVerifiedOp<SignedBlsToExecutionChange, E>>, received_pre_capella_changes: Vec<SigVerifiedOp<SignedBlsToExecutionChange, E>>,
/// Changes which should *not* be broadcast at the Capella fork. /// Changes which should *not* be broadcast at the Capella fork.

View File

@ -1,8 +1,5 @@
use beacon_chain::{ use beacon_chain::{
test_utils::{ test_utils::{BeaconChainHarness, BoxedMutator, Builder, EphemeralHarnessType},
BeaconChainHarness, BoxedMutator, Builder,
EphemeralTestingSlotClockHarnessType as HarnessType,
},
BeaconChain, BeaconChainTypes, BeaconChain, BeaconChainTypes,
}; };
use directory::DEFAULT_ROOT_DIR; use directory::DEFAULT_ROOT_DIR;
@ -41,7 +38,7 @@ pub const EXTERNAL_ADDR: &str = "/ip4/0.0.0.0/tcp/9000";
/// HTTP API tester that allows interaction with the underlying beacon chain harness. /// HTTP API tester that allows interaction with the underlying beacon chain harness.
pub struct InteractiveTester<E: EthSpec> { pub struct InteractiveTester<E: EthSpec> {
pub harness: BeaconChainHarness<HarnessType<E>>, pub harness: BeaconChainHarness<EphemeralHarnessType<E>>,
pub client: BeaconNodeHttpClient, pub client: BeaconNodeHttpClient,
pub network_rx: NetworkReceivers<E>, pub network_rx: NetworkReceivers<E>,
_server_shutdown: oneshot::Sender<()>, _server_shutdown: oneshot::Sender<()>,
@ -59,7 +56,7 @@ pub struct ApiServer<E: EthSpec, SFut: Future<Output = ()>> {
pub external_peer_id: PeerId, pub external_peer_id: PeerId,
} }
type HarnessBuilder<E> = Builder<HarnessType<E>, TestingSlotClock>; type HarnessBuilder<E> = Builder<EphemeralHarnessType<E>, TestingSlotClock>;
type Initializer<E> = Box<dyn FnOnce(HarnessBuilder<E>) -> HarnessBuilder<E>>; type Initializer<E> = Box<dyn FnOnce(HarnessBuilder<E>) -> HarnessBuilder<E>>;
type Mutator<E> = BoxedMutator<E, MemoryStore<E>, MemoryStore<E>, TestingSlotClock>; type Mutator<E> = BoxedMutator<E, MemoryStore<E>, MemoryStore<E>, TestingSlotClock>;

View File

@ -1,10 +1,7 @@
use crate::common::{create_api_server, create_api_server_on_port, ApiServer}; use crate::common::{create_api_server, create_api_server_on_port, ApiServer};
use beacon_chain::test_utils::RelativeSyncCommittee; use beacon_chain::test_utils::RelativeSyncCommittee;
use beacon_chain::{ use beacon_chain::{
test_utils::{ test_utils::{AttestationStrategy, BeaconChainHarness, BlockStrategy, EphemeralHarnessType},
AttestationStrategy, BeaconChainHarness, BlockStrategy,
EphemeralTestingSlotClockHarnessType,
},
BeaconChain, StateSkipConfig, WhenSlotSkipped, MAXIMUM_GOSSIP_CLOCK_DISPARITY, BeaconChain, StateSkipConfig, WhenSlotSkipped, MAXIMUM_GOSSIP_CLOCK_DISPARITY,
}; };
use environment::null_logger; use environment::null_logger;
@ -60,8 +57,8 @@ const SKIPPED_SLOTS: &[u64] = &[
]; ];
struct ApiTester { struct ApiTester {
harness: Arc<BeaconChainHarness<EphemeralTestingSlotClockHarnessType<E>>>, harness: Arc<BeaconChainHarness<EphemeralHarnessType<E>>>,
chain: Arc<BeaconChain<EphemeralTestingSlotClockHarnessType<E>>>, chain: Arc<BeaconChain<EphemeralHarnessType<E>>>,
client: BeaconNodeHttpClient, client: BeaconNodeHttpClient,
next_block: SignedBeaconBlock<E>, next_block: SignedBeaconBlock<E>,
reorg_block: SignedBeaconBlock<E>, reorg_block: SignedBeaconBlock<E>,

View File

@ -1,4 +1,4 @@
use beacon_chain::test_utils::EphemeralTestingSlotClockHarnessType; use beacon_chain::test_utils::EphemeralHarnessType;
use environment::null_logger; use environment::null_logger;
use http_metrics::Config; use http_metrics::Config;
use reqwest::StatusCode; use reqwest::StatusCode;
@ -7,7 +7,7 @@ use std::sync::Arc;
use tokio::sync::oneshot; use tokio::sync::oneshot;
use types::MainnetEthSpec; use types::MainnetEthSpec;
type Context = http_metrics::Context<EphemeralTestingSlotClockHarnessType<MainnetEthSpec>>; type Context = http_metrics::Context<EphemeralHarnessType<MainnetEthSpec>>;
#[tokio::test(flavor = "multi_thread", worker_threads = 2)] #[tokio::test(flavor = "multi_thread", worker_threads = 2)]
async fn returns_200_ok() { async fn returns_200_ok() {

View File

@ -7,7 +7,7 @@ use crate::beacon_processor::work_reprocessing_queue::{
use crate::beacon_processor::*; use crate::beacon_processor::*;
use crate::{service::NetworkMessage, sync::SyncMessage}; use crate::{service::NetworkMessage, sync::SyncMessage};
use beacon_chain::test_utils::{ use beacon_chain::test_utils::{
AttestationStrategy, BeaconChainHarness, BlockStrategy, EphemeralTestingSlotClockHarnessType, AttestationStrategy, BeaconChainHarness, BlockStrategy, EphemeralHarnessType,
}; };
use beacon_chain::{BeaconChain, MAXIMUM_GOSSIP_CLOCK_DISPARITY}; use beacon_chain::{BeaconChain, MAXIMUM_GOSSIP_CLOCK_DISPARITY};
use lighthouse_network::{ use lighthouse_network::{
@ -28,7 +28,7 @@ use types::{
}; };
type E = MainnetEthSpec; type E = MainnetEthSpec;
type T = EphemeralTestingSlotClockHarnessType<E>; type T = EphemeralHarnessType<E>;
const SLOTS_PER_EPOCH: u64 = 32; const SLOTS_PER_EPOCH: u64 = 32;
const VALIDATOR_COUNT: usize = SLOTS_PER_EPOCH as usize; const VALIDATOR_COUNT: usize = SLOTS_PER_EPOCH as usize;

View File

@ -3,9 +3,7 @@
mod tests { mod tests {
use crate::persisted_dht::load_dht; use crate::persisted_dht::load_dht;
use crate::{NetworkConfig, NetworkService}; use crate::{NetworkConfig, NetworkService};
use beacon_chain::test_utils::{ use beacon_chain::test_utils::{BeaconChainHarness, EphemeralHarnessType};
BeaconChainHarness, EphemeralSystemTimeSlotClockHarnessType as HarnessType,
};
use lighthouse_network::Enr; use lighthouse_network::Enr;
use slog::{o, Drain, Level, Logger}; use slog::{o, Drain, Level, Logger};
use sloggers::{null::NullLoggerBuilder, Build}; use sloggers::{null::NullLoggerBuilder, Build};
@ -36,7 +34,7 @@ mod tests {
fn test_dht_persistence() { fn test_dht_persistence() {
let log = get_logger(false); let log = get_logger(false);
let beacon_chain = BeaconChainHarness::<HarnessType<E>>::builder(E) let beacon_chain = BeaconChainHarness::EphemeralHarnessType::<E>::builder(E)
.default_spec() .default_spec()
.deterministic_keypairs(8) .deterministic_keypairs(8)
.fresh_ephemeral_store() .fresh_ephemeral_store()

View File

@ -9,9 +9,7 @@ use super::*;
use beacon_chain::{ use beacon_chain::{
builder::Witness, builder::Witness,
eth1_chain::CachingEth1Backend, eth1_chain::CachingEth1Backend,
test_utils::{ test_utils::{build_log, BeaconChainHarness, EphemeralHarnessType},
build_log, BeaconChainHarness, EphemeralSystemTimeSlotClockHarnessType as HarnessType,
},
}; };
pub use genesis::{interop_genesis_state, DEFAULT_ETH1_BLOCK_HASH}; pub use genesis::{interop_genesis_state, DEFAULT_ETH1_BLOCK_HASH};
use lighthouse_network::{NetworkGlobals, Request}; use lighthouse_network::{NetworkGlobals, Request};
@ -39,7 +37,7 @@ impl TestRig {
let log = build_log(slog::Level::Debug, enable_log); let log = build_log(slog::Level::Debug, enable_log);
// Initialise a new beacon chain // Initialise a new beacon chain
let harness = BeaconChainHarness::<HarnessType<E>>::builder(E::default()) let harness = BeaconChainHarness::<EphemeralHarnessType<E>>::builder(E::default())
.default_spec() .default_spec()
.logger(log.clone()) .logger(log.clone())
.deterministic_keypairs(1) .deterministic_keypairs(1)

View File

@ -381,9 +381,7 @@ mod tests {
builder::Witness, builder::Witness,
eth1_chain::CachingEth1Backend, eth1_chain::CachingEth1Backend,
parking_lot::RwLock, parking_lot::RwLock,
test_utils::{ test_utils::{build_log, BeaconChainHarness, EphemeralHarnessType},
build_log, BeaconChainHarness, EphemeralSystemTimeSlotClockHarnessType as HarnessType,
},
EngineState, EngineState,
}; };
use lighthouse_network::{ use lighthouse_network::{
@ -586,7 +584,7 @@ mod tests {
fn range(log_enabled: bool) -> (TestRig, RangeSync<TestBeaconChainType, FakeStorage>) { fn range(log_enabled: bool) -> (TestRig, RangeSync<TestBeaconChainType, FakeStorage>) {
let log = build_log(slog::Level::Trace, log_enabled); let log = build_log(slog::Level::Trace, log_enabled);
// Initialise a new beacon chain // Initialise a new beacon chain
let harness = BeaconChainHarness::<HarnessType<E>>::builder(E::default()) let harness = BeaconChainHarness::<EphemeralHarnessType<E>>::builder(E::default())
.default_spec() .default_spec()
.logger(log.clone()) .logger(log.clone())
.deterministic_keypairs(1) .deterministic_keypairs(1)

View File

@ -768,7 +768,7 @@ mod release_tests {
use super::attestation::earliest_attestation_validators; use super::attestation::earliest_attestation_validators;
use super::*; use super::*;
use beacon_chain::test_utils::{ use beacon_chain::test_utils::{
test_spec, BeaconChainHarness, EphemeralTestingSlotClockHarnessType, RelativeSyncCommittee, test_spec, BeaconChainHarness, EphemeralHarnessType, RelativeSyncCommittee,
}; };
use lazy_static::lazy_static; use lazy_static::lazy_static;
use maplit::hashset; use maplit::hashset;
@ -787,7 +787,7 @@ mod release_tests {
fn get_harness<E: EthSpec>( fn get_harness<E: EthSpec>(
validator_count: usize, validator_count: usize,
spec: Option<ChainSpec>, spec: Option<ChainSpec>,
) -> BeaconChainHarness<EphemeralTestingSlotClockHarnessType<E>> { ) -> BeaconChainHarness<EphemeralHarnessType<E>> {
let harness = BeaconChainHarness::builder(E::default()) let harness = BeaconChainHarness::builder(E::default())
.spec_or_default(spec) .spec_or_default(spec)
.keypairs(KEYPAIRS[0..validator_count].to_vec()) .keypairs(KEYPAIRS[0..validator_count].to_vec())
@ -803,10 +803,7 @@ mod release_tests {
/// Test state for attestation-related tests. /// Test state for attestation-related tests.
fn attestation_test_state<E: EthSpec>( fn attestation_test_state<E: EthSpec>(
num_committees: usize, num_committees: usize,
) -> ( ) -> (BeaconChainHarness<EphemeralHarnessType<E>>, ChainSpec) {
BeaconChainHarness<EphemeralTestingSlotClockHarnessType<E>>,
ChainSpec,
) {
let spec = test_spec::<E>(); let spec = test_spec::<E>();
let num_validators = let num_validators =
@ -819,10 +816,7 @@ mod release_tests {
/// Test state for sync contribution-related tests. /// Test state for sync contribution-related tests.
async fn sync_contribution_test_state<E: EthSpec>( async fn sync_contribution_test_state<E: EthSpec>(
num_committees: usize, num_committees: usize,
) -> ( ) -> (BeaconChainHarness<EphemeralHarnessType<E>>, ChainSpec) {
BeaconChainHarness<EphemeralTestingSlotClockHarnessType<E>>,
ChainSpec,
) {
let mut spec = E::default_spec(); let mut spec = E::default_spec();
spec.altair_fork_epoch = Some(Epoch::new(0)); spec.altair_fork_epoch = Some(Epoch::new(0));
@ -1792,10 +1786,8 @@ mod release_tests {
); );
} }
fn cross_fork_harness<E: EthSpec>() -> ( fn cross_fork_harness<E: EthSpec>() -> (BeaconChainHarness<EphemeralHarnessType<E>>, ChainSpec)
BeaconChainHarness<EphemeralTestingSlotClockHarnessType<E>>, {
ChainSpec,
) {
let mut spec = E::default_spec(); let mut spec = E::default_spec();
// Give some room to sign surround slashings. // Give some room to sign surround slashings.

View File

@ -5,7 +5,7 @@ use std::sync::Mutex;
use std::time::Duration; use std::time::Duration;
use beacon_chain::test_utils::{ use beacon_chain::test_utils::{
AttestationStrategy, BeaconChainHarness, BlockStrategy, EphemeralTestingSlotClockHarnessType, AttestationStrategy, BeaconChainHarness, BlockStrategy, EphemeralHarnessType,
}; };
use beacon_chain::{ use beacon_chain::{
BeaconChain, BeaconChainError, BeaconForkChoiceStore, ChainConfig, ForkChoiceError, BeaconChain, BeaconChainError, BeaconForkChoiceStore, ChainConfig, ForkChoiceError,
@ -35,7 +35,7 @@ pub enum MutationDelay {
/// A helper struct to make testing fork choice more ergonomic and less repetitive. /// A helper struct to make testing fork choice more ergonomic and less repetitive.
struct ForkChoiceTest { struct ForkChoiceTest {
harness: BeaconChainHarness<EphemeralTestingSlotClockHarnessType<E>>, harness: BeaconChainHarness<EphemeralHarnessType<E>>,
} }
/// Allows us to use `unwrap` in some cases. /// Allows us to use `unwrap` in some cases.
@ -397,7 +397,7 @@ impl ForkChoiceTest {
mut comparison_func: G, mut comparison_func: G,
) -> Self ) -> Self
where where
F: FnMut(&mut IndexedAttestation<E>, &BeaconChain<EphemeralTestingSlotClockHarnessType<E>>), F: FnMut(&mut IndexedAttestation<E>, &BeaconChain<EphemeralHarnessType<E>>),
G: FnMut(Result<(), BeaconChainError>), G: FnMut(Result<(), BeaconChainError>),
{ {
let head = self.harness.chain.head_snapshot(); let head = self.harness.chain.head_snapshot();

View File

@ -10,9 +10,7 @@ use crate::{
per_block_processing::{process_operations, verify_exit::verify_exit}, per_block_processing::{process_operations, verify_exit::verify_exit},
BlockSignatureStrategy, ConsensusContext, VerifyBlockRoot, VerifySignatures, BlockSignatureStrategy, ConsensusContext, VerifyBlockRoot, VerifySignatures,
}; };
use beacon_chain::test_utils::{ use beacon_chain::test_utils::{BeaconChainHarness, EphemeralHarnessType};
BeaconChainHarness, EphemeralTestingSlotClockHarnessType as HarnessType,
};
use lazy_static::lazy_static; use lazy_static::lazy_static;
use ssz_types::Bitfield; use ssz_types::Bitfield;
use test_utils::generate_deterministic_keypairs; use test_utils::generate_deterministic_keypairs;
@ -32,11 +30,11 @@ lazy_static! {
async fn get_harness<E: EthSpec>( async fn get_harness<E: EthSpec>(
epoch_offset: u64, epoch_offset: u64,
num_validators: usize, num_validators: usize,
) -> BeaconChainHarness<HarnessType<E>> { ) -> BeaconChainHarness<EphemeralHarnessType<E>> {
// Set the state and block to be in the last slot of the `epoch_offset`th epoch. // Set the state and block to be in the last slot of the `epoch_offset`th epoch.
let last_slot_of_epoch = let last_slot_of_epoch =
(MainnetEthSpec::genesis_epoch() + epoch_offset).end_slot(E::slots_per_epoch()); (MainnetEthSpec::genesis_epoch() + epoch_offset).end_slot(E::slots_per_epoch());
let harness = BeaconChainHarness::<HarnessType<E>>::builder(E::default()) let harness = BeaconChainHarness::<EphemeralHarnessType<E>>::builder(E::default())
.default_spec() .default_spec()
.keypairs(KEYPAIRS[0..num_validators].to_vec()) .keypairs(KEYPAIRS[0..num_validators].to_vec())
.fresh_ephemeral_store() .fresh_ephemeral_store()

View File

@ -1,10 +1,10 @@
use beacon_chain::test_utils::{BeaconChainHarness, EphemeralTestingSlotClockHarnessType}; use beacon_chain::test_utils::{BeaconChainHarness, EphemeralHarnessType};
use types::{BeaconState, EthSpec, MainnetEthSpec}; use types::{BeaconState, EthSpec, MainnetEthSpec};
const TREE_HASH_LOOPS: usize = 1_000; const TREE_HASH_LOOPS: usize = 1_000;
const VALIDATOR_COUNT: usize = 1_000; const VALIDATOR_COUNT: usize = 1_000;
fn get_harness<T: EthSpec>() -> BeaconChainHarness<EphemeralTestingSlotClockHarnessType<T>> { fn get_harness<T: EthSpec>() -> BeaconChainHarness<EphemeralHarnessType<T>> {
let harness = BeaconChainHarness::builder(T::default()) let harness = BeaconChainHarness::builder(T::default())
.default_spec() .default_spec()
.deterministic_keypairs(VALIDATOR_COUNT) .deterministic_keypairs(VALIDATOR_COUNT)

View File

@ -1,8 +1,6 @@
#![cfg(test)] #![cfg(test)]
use crate::test_utils::*; use crate::test_utils::*;
use beacon_chain::test_utils::{ use beacon_chain::test_utils::{BeaconChainHarness, EphemeralHarnessType};
BeaconChainHarness, EphemeralTestingSlotClockHarnessType as HarnessType,
};
use beacon_chain::types::*; use beacon_chain::types::*;
use swap_or_not_shuffle::shuffle_list; use swap_or_not_shuffle::shuffle_list;
@ -13,7 +11,7 @@ lazy_static! {
static ref KEYPAIRS: Vec<Keypair> = generate_deterministic_keypairs(VALIDATOR_COUNT); static ref KEYPAIRS: Vec<Keypair> = generate_deterministic_keypairs(VALIDATOR_COUNT);
} }
fn get_harness<E: EthSpec>(validator_count: usize) -> BeaconChainHarness<HarnessType<E>> { fn get_harness<E: EthSpec>(validator_count: usize) -> BeaconChainHarness<EphemeralHarnessType<E>> {
let harness = BeaconChainHarness::builder(E::default()) let harness = BeaconChainHarness::builder(E::default())
.default_spec() .default_spec()
.keypairs(KEYPAIRS[0..validator_count].to_vec()) .keypairs(KEYPAIRS[0..validator_count].to_vec())

View File

@ -2,8 +2,8 @@
use crate::test_utils::*; use crate::test_utils::*;
use crate::test_utils::{SeedableRng, XorShiftRng}; use crate::test_utils::{SeedableRng, XorShiftRng};
use beacon_chain::test_utils::{ use beacon_chain::test_utils::{
interop_genesis_state_with_eth1, test_spec, BeaconChainHarness, interop_genesis_state_with_eth1, test_spec, BeaconChainHarness, EphemeralHarnessType,
EphemeralTestingSlotClockHarnessType as HarnessType, DEFAULT_ETH1_BLOCK_HASH, DEFAULT_ETH1_BLOCK_HASH,
}; };
use beacon_chain::types::{ use beacon_chain::types::{
test_utils::TestRandom, BeaconState, BeaconStateAltair, BeaconStateBase, BeaconStateError, test_utils::TestRandom, BeaconState, BeaconStateAltair, BeaconStateBase, BeaconStateError,
@ -28,7 +28,7 @@ lazy_static! {
async fn get_harness<E: EthSpec>( async fn get_harness<E: EthSpec>(
validator_count: usize, validator_count: usize,
slot: Slot, slot: Slot,
) -> BeaconChainHarness<HarnessType<E>> { ) -> BeaconChainHarness<EphemeralHarnessType<E>> {
let harness = BeaconChainHarness::builder(E::default()) let harness = BeaconChainHarness::builder(E::default())
.default_spec() .default_spec()
.keypairs(KEYPAIRS[0..validator_count].to_vec()) .keypairs(KEYPAIRS[0..validator_count].to_vec())

View File

@ -62,7 +62,7 @@
//! --exclude-post-block-thc //! --exclude-post-block-thc
//! ``` //! ```
use beacon_chain::{ use beacon_chain::{
test_utils::EphemeralTestingSlotClockHarnessType, validator_pubkey_cache::ValidatorPubkeyCache, test_utils::EphemeralHarnessType, validator_pubkey_cache::ValidatorPubkeyCache,
}; };
use clap::ArgMatches; use clap::ArgMatches;
use clap_utils::{parse_optional, parse_required}; use clap_utils::{parse_optional, parse_required};
@ -297,7 +297,7 @@ fn do_transition<T: EthSpec>(
block: SignedBeaconBlock<T>, block: SignedBeaconBlock<T>,
mut state_root_opt: Option<Hash256>, mut state_root_opt: Option<Hash256>,
config: &Config, config: &Config,
validator_pubkey_cache: &ValidatorPubkeyCache<EphemeralTestingSlotClockHarnessType<T>>, validator_pubkey_cache: &ValidatorPubkeyCache<EphemeralHarnessType<T>>,
spec: &ChainSpec, spec: &ChainSpec,
) -> Result<BeaconState<T>, String> { ) -> Result<BeaconState<T>, String> {
if !config.exclude_cache_builds { if !config.exclude_cache_builds {

View File

@ -6,7 +6,7 @@ use beacon_chain::{
attestation_verification::{ attestation_verification::{
obtain_indexed_attestation_and_committees_per_slot, VerifiedAttestation, obtain_indexed_attestation_and_committees_per_slot, VerifiedAttestation,
}, },
test_utils::{BeaconChainHarness, EphemeralTestingSlotClockHarnessType}, test_utils::{BeaconChainHarness, EphemeralHarnessType},
BeaconChainTypes, CachedHead, CountUnrealized, NotifyExecutionLayer, BeaconChainTypes, CachedHead, CountUnrealized, NotifyExecutionLayer,
}; };
use execution_layer::{json_structures::JsonPayloadStatusV1Status, PayloadStatusV1}; use execution_layer::{json_structures::JsonPayloadStatusV1Status, PayloadStatusV1};
@ -286,7 +286,7 @@ impl<E: EthSpec> Case for ForkChoiceTest<E> {
/// A testing rig used to execute a test case. /// A testing rig used to execute a test case.
struct Tester<E: EthSpec> { struct Tester<E: EthSpec> {
harness: BeaconChainHarness<EphemeralTestingSlotClockHarnessType<E>>, harness: BeaconChainHarness<EphemeralHarnessType<E>>,
spec: ChainSpec, spec: ChainSpec,
} }
@ -306,15 +306,14 @@ impl<E: EthSpec> Tester<E> {
)); ));
} }
let harness = let harness = BeaconChainHarness::<EphemeralHarnessType<E>>::builder(E::default())
BeaconChainHarness::<EphemeralTestingSlotClockHarnessType<E>>::builder(E::default()) .spec(spec.clone())
.spec(spec.clone()) .keypairs(vec![])
.keypairs(vec![]) .genesis_state_ephemeral_store(case.anchor_state.clone())
.genesis_state_ephemeral_store(case.anchor_state.clone()) .mock_execution_layer()
.mock_execution_layer() .recalculate_fork_times_with_genesis(0)
.recalculate_fork_times_with_genesis(0) .mock_execution_layer_all_payloads_valid()
.mock_execution_layer_all_payloads_valid() .build();
.build();
if harness.chain.genesis_block_root != case.anchor_block.canonical_root() { if harness.chain.genesis_block_root != case.anchor_block.canonical_root() {
// This check will need to be removed if/when the fork-choice tests use a non-genesis // This check will need to be removed if/when the fork-choice tests use a non-genesis
@ -470,12 +469,11 @@ impl<E: EthSpec> Tester<E> {
.map_err(|e| { .map_err(|e| {
Error::InternalError(format!("attestation indexing failed with {:?}", e)) Error::InternalError(format!("attestation indexing failed with {:?}", e))
})?; })?;
let verified_attestation: ManuallyVerifiedAttestation< let verified_attestation: ManuallyVerifiedAttestation<EphemeralHarnessType<E>> =
EphemeralTestingSlotClockHarnessType<E>, ManuallyVerifiedAttestation {
> = ManuallyVerifiedAttestation { attestation,
attestation, indexed_attestation,
indexed_attestation, };
};
self.harness self.harness
.chain .chain

View File

@ -1,5 +1,5 @@
use super::*; use super::*;
use beacon_chain::test_utils::{BeaconChainHarness, EphemeralTestingSlotClockHarnessType}; use beacon_chain::test_utils::{BeaconChainHarness, EphemeralHarnessType};
use state_processing::{ use state_processing::{
per_block_processing, per_block_processing::errors::ExitInvalid, BlockProcessingError, per_block_processing, per_block_processing::errors::ExitInvalid, BlockProcessingError,
BlockSignatureStrategy, ConsensusContext, VerifyBlockRoot, BlockSignatureStrategy, ConsensusContext, VerifyBlockRoot,
@ -18,12 +18,8 @@ struct ExitTest {
#[allow(clippy::type_complexity)] #[allow(clippy::type_complexity)]
state_modifier: Box<dyn FnOnce(&mut BeaconState<E>)>, state_modifier: Box<dyn FnOnce(&mut BeaconState<E>)>,
#[allow(clippy::type_complexity)] #[allow(clippy::type_complexity)]
block_modifier: Box< block_modifier:
dyn FnOnce( Box<dyn FnOnce(&BeaconChainHarness<EphemeralHarnessType<E>>, &mut BeaconBlock<E>)>,
&BeaconChainHarness<EphemeralTestingSlotClockHarnessType<E>>,
&mut BeaconBlock<E>,
),
>,
#[allow(dead_code)] #[allow(dead_code)]
expected: Result<(), BlockProcessingError>, expected: Result<(), BlockProcessingError>,
} }

View File

@ -2,7 +2,7 @@
mod macros; mod macros;
mod exit; mod exit;
use beacon_chain::test_utils::{BeaconChainHarness, EphemeralTestingSlotClockHarnessType}; use beacon_chain::test_utils::{BeaconChainHarness, EphemeralHarnessType};
use lazy_static::lazy_static; use lazy_static::lazy_static;
use ssz::Encode; use ssz::Encode;
use std::env; use std::env;
@ -53,7 +53,7 @@ lazy_static! {
async fn get_harness<E: EthSpec>( async fn get_harness<E: EthSpec>(
slot: Slot, slot: Slot,
validator_count: usize, validator_count: usize,
) -> BeaconChainHarness<EphemeralTestingSlotClockHarnessType<E>> { ) -> BeaconChainHarness<EphemeralHarnessType<E>> {
let harness = BeaconChainHarness::builder(E::default()) let harness = BeaconChainHarness::builder(E::default())
.default_spec() .default_spec()
.keypairs(KEYPAIRS[0..validator_count].to_vec()) .keypairs(KEYPAIRS[0..validator_count].to_vec())