Fix various clippy lints

This commit is contained in:
Paul Hauner 2019-02-13 07:32:31 +11:00
parent 5039001eba
commit 5c1d0dcea5
No known key found for this signature in database
GPG Key ID: D362883A9218FCC6
17 changed files with 105 additions and 110 deletions

View File

@ -61,8 +61,7 @@ impl BeaconChainHarness {
debug!("Creating validator deposits..."); debug!("Creating validator deposits...");
let mut initial_validator_deposits = Vec::with_capacity(validator_count); let initial_validator_deposits = keypairs
initial_validator_deposits = keypairs
.par_iter() .par_iter()
.map(|keypair| Deposit { .map(|keypair| Deposit {
branch: vec![], // branch verification is not specified. branch: vec![], // branch verification is not specified.
@ -235,7 +234,7 @@ impl BeaconChainHarness {
} }
/// Write the output of `chain_dump` to a JSON file. /// Write the output of `chain_dump` to a JSON file.
pub fn dump_to_file(&self, filename: String, chain_dump: &Vec<CheckPoint>) { pub fn dump_to_file(&self, filename: String, chain_dump: &[CheckPoint]) {
let json = serde_json::to_string(chain_dump).unwrap(); let json = serde_json::to_string(chain_dump).unwrap();
let mut file = File::create(filename).unwrap(); let mut file = File::create(filename).unwrap();
file.write_all(json.as_bytes()) file.write_all(json.as_bytes())

View File

@ -80,7 +80,7 @@ impl<T: ClientDB, U: SlotClock> BeaconBlockNode for DirectBeaconNode<T, U> {
.beacon_chain .beacon_chain
.produce_block(randao_reveal.clone()) .produce_block(randao_reveal.clone())
.ok_or_else(|| { .ok_or_else(|| {
BeaconBlockNodeError::RemoteFailure(format!("Did not produce block.")) BeaconBlockNodeError::RemoteFailure("Did not produce block.".to_string())
})?; })?;
if block.slot == slot { if block.slot == slot {

View File

@ -60,7 +60,7 @@ impl<T: ClientDB, U: SlotClock> AttesterDutiesReader for DirectDuties<T, U> {
} }
Ok(Some(_)) => Ok(None), Ok(Some(_)) => Ok(None),
Ok(None) => Err(AttesterDutiesReaderError::UnknownEpoch), Ok(None) => Err(AttesterDutiesReaderError::UnknownEpoch),
Err(_) => panic!("Error when getting validator attestation shard."), Err(_) => unreachable!("Error when getting validator attestation shard."),
} }
} else { } else {
Err(AttesterDutiesReaderError::UnknownValidator) Err(AttesterDutiesReaderError::UnknownValidator)

View File

@ -25,7 +25,7 @@ impl BeaconBlockService for BeaconBlockServiceInstance {
// TODO: build a legit block. // TODO: build a legit block.
let mut block = BeaconBlockProto::new(); let mut block = BeaconBlockProto::new();
block.set_slot(req.get_slot()); block.set_slot(req.get_slot());
block.set_block_root("cats".as_bytes().to_vec()); block.set_block_root(b"cats".to_vec());
let mut resp = ProduceBeaconBlockResponse::new(); let mut resp = ProduceBeaconBlockResponse::new();
resp.set_block(block); resp.set_block(block);

View File

@ -2,7 +2,6 @@ use crate::traits::{BeaconNode, BeaconNodeError, PublishOutcome};
use std::sync::RwLock; use std::sync::RwLock;
use types::{BeaconBlock, Signature, Slot}; use types::{BeaconBlock, Signature, Slot};
type NonceResult = Result<u64, BeaconNodeError>;
type ProduceResult = Result<Option<BeaconBlock>, BeaconNodeError>; type ProduceResult = Result<Option<BeaconBlock>, BeaconNodeError>;
type PublishResult = Result<PublishOutcome, BeaconNodeError>; type PublishResult = Result<PublishOutcome, BeaconNodeError>;

View File

@ -333,7 +333,7 @@ fn validate_attestation_signature_optional(
ensure!( ensure!(
(attestation.data.latest_crosslink (attestation.data.latest_crosslink
== state.latest_crosslinks[attestation.data.shard as usize]) == state.latest_crosslinks[attestation.data.shard as usize])
|| (attestation.data.latest_crosslink | (attestation.data.latest_crosslink
== state.latest_crosslinks[attestation.data.shard as usize]), == state.latest_crosslinks[attestation.data.shard as usize]),
AttestationValidationError::BadLatestCrosslinkRoot AttestationValidationError::BadLatestCrosslinkRoot
); );

View File

@ -226,7 +226,7 @@ impl EpochProcessable for BeaconState {
*/ */
let mut new_justified_epoch = self.justified_epoch; let mut new_justified_epoch = self.justified_epoch;
self.justification_bitfield = self.justification_bitfield << 1; self.justification_bitfield <<= 1;
// If > 2/3 of the total balance attested to the previous epoch boundary // If > 2/3 of the total balance attested to the previous epoch boundary
// //
@ -277,8 +277,7 @@ impl EpochProcessable for BeaconState {
// - The presently justified epoch was two epochs ago. // - The presently justified epoch was two epochs ago.
// //
// Then, set the finalized epoch to two epochs ago. // Then, set the finalized epoch to two epochs ago.
if ((self.justification_bitfield >> 0) % 8 == 0b111) if (self.justification_bitfield % 8 == 0b111) & (self.justified_epoch == previous_epoch - 1)
& (self.justified_epoch == previous_epoch - 1)
{ {
self.finalized_epoch = self.justified_epoch; self.finalized_epoch = self.justified_epoch;
trace!("epoch - 2 was finalized (3rd condition)."); trace!("epoch - 2 was finalized (3rd condition).");
@ -289,9 +288,7 @@ impl EpochProcessable for BeaconState {
// - Set the previous epoch to be justified. // - Set the previous epoch to be justified.
// //
// Then, set the finalized epoch to be the previous epoch. // Then, set the finalized epoch to be the previous epoch.
if ((self.justification_bitfield >> 0) % 4 == 0b11) if (self.justification_bitfield % 4 == 0b11) & (self.justified_epoch == previous_epoch) {
& (self.justified_epoch == previous_epoch)
{
self.finalized_epoch = self.justified_epoch; self.finalized_epoch = self.justified_epoch;
trace!("epoch - 1 was finalized (4th condition)."); trace!("epoch - 1 was finalized (4th condition).");
} }
@ -386,10 +383,8 @@ impl EpochProcessable for BeaconState {
base_reward * previous_epoch_justified_attesting_balance base_reward * previous_epoch_justified_attesting_balance
/ previous_total_balance / previous_total_balance
); );
} else { } else if active_validator_indices_hashset.contains(&index) {
if active_validator_indices_hashset.contains(&index) { safe_sub_assign!(self.validator_balances[index], base_reward);
safe_sub_assign!(self.validator_balances[index], base_reward);
}
} }
if previous_epoch_boundary_attester_indices_hashset.contains(&index) { if previous_epoch_boundary_attester_indices_hashset.contains(&index) {
@ -398,10 +393,8 @@ impl EpochProcessable for BeaconState {
base_reward * previous_epoch_boundary_attesting_balance base_reward * previous_epoch_boundary_attesting_balance
/ previous_total_balance / previous_total_balance
); );
} else { } else if active_validator_indices_hashset.contains(&index) {
if active_validator_indices_hashset.contains(&index) { safe_sub_assign!(self.validator_balances[index], base_reward);
safe_sub_assign!(self.validator_balances[index], base_reward);
}
} }
if previous_epoch_head_attester_indices_hashset.contains(&index) { if previous_epoch_head_attester_indices_hashset.contains(&index) {
@ -410,10 +403,8 @@ impl EpochProcessable for BeaconState {
base_reward * previous_epoch_head_attesting_balance base_reward * previous_epoch_head_attesting_balance
/ previous_total_balance / previous_total_balance
); );
} else { } else if active_validator_indices_hashset.contains(&index) {
if active_validator_indices_hashset.contains(&index) { safe_sub_assign!(self.validator_balances[index], base_reward);
safe_sub_assign!(self.validator_balances[index], base_reward);
}
} }
} }
@ -505,7 +496,7 @@ impl EpochProcessable for BeaconState {
if let Some(Ok(winning_root)) = winning_root_for_shards.get(&shard) { if let Some(Ok(winning_root)) = winning_root_for_shards.get(&shard) {
// TODO: remove the map. // TODO: remove the map.
let attesting_validator_indices: HashSet<usize> = HashSet::from_iter( let attesting_validator_indices: HashSet<usize> = HashSet::from_iter(
winning_root.attesting_validator_indices.iter().map(|i| *i), winning_root.attesting_validator_indices.iter().cloned(),
); );
for index in 0..self.validator_balances.len() { for index in 0..self.validator_balances.len() {
@ -664,7 +655,7 @@ fn winning_root(
} }
let candidate_root = WinningRoot { let candidate_root = WinningRoot {
shard_block_root: shard_block_root.clone(), shard_block_root: *shard_block_root,
attesting_validator_indices, attesting_validator_indices,
total_attesting_balance, total_attesting_balance,
total_balance, total_balance,

View File

@ -30,8 +30,6 @@ where
self.slot += 1; self.slot += 1;
let block_proposer = self.get_beacon_proposer_index(self.slot, spec)?;
self.latest_randao_mixes[self.slot.as_usize() % spec.latest_randao_mixes_length] = self.latest_randao_mixes[self.slot.as_usize() % spec.latest_randao_mixes_length] =
self.latest_randao_mixes[(self.slot.as_usize() - 1) % spec.latest_randao_mixes_length]; self.latest_randao_mixes[(self.slot.as_usize() - 1) % spec.latest_randao_mixes_length];

View File

@ -1,6 +1,5 @@
use super::{AggregatePublicKey, AggregateSignature, AttestationData, Bitfield, Hash256}; use super::{AggregatePublicKey, AggregateSignature, AttestationData, Bitfield, Hash256};
use crate::test_utils::TestRandom; use crate::test_utils::TestRandom;
use bls::bls_verify_aggregate;
use rand::RngCore; use rand::RngCore;
use serde_derive::Serialize; use serde_derive::Serialize;
use ssz::{hash, Decodable, DecodeError, Encodable, SszStream, TreeHash}; use ssz::{hash, Decodable, DecodeError, Encodable, SszStream, TreeHash};

View File

@ -283,7 +283,7 @@ impl BeaconState {
shuffled_active_validator_indices shuffled_active_validator_indices
.honey_badger_split(committees_per_epoch as usize) .honey_badger_split(committees_per_epoch as usize)
.filter_map(|slice: &[usize]| Some(slice.to_vec())) .map(|slice: &[usize]| slice.to_vec())
.collect() .collect()
} }
@ -522,11 +522,9 @@ impl BeaconState {
.filter(|i| eligible(*i)) .filter(|i| eligible(*i))
.collect(); .collect();
eligable_indices.sort_by_key(|i| self.validator_registry[*i].exit_epoch); eligable_indices.sort_by_key(|i| self.validator_registry[*i].exit_epoch);
let mut withdrawn_so_far = 0; for (withdrawn_so_far, index) in eligable_indices.iter().enumerate() {
for index in eligable_indices { self.prepare_validator_for_withdrawal(*index);
self.prepare_validator_for_withdrawal(index); if withdrawn_so_far as u64 >= spec.max_withdrawals_per_epoch {
withdrawn_so_far += 1;
if withdrawn_so_far >= spec.max_withdrawals_per_epoch {
break; break;
} }
} }
@ -796,11 +794,7 @@ impl BeaconState {
for (i, a) in attestations.iter().enumerate() { for (i, a) in attestations.iter().enumerate() {
let participants = let participants =
self.get_attestation_participants(&a.data, &a.aggregation_bitfield, spec)?; self.get_attestation_participants(&a.data, &a.aggregation_bitfield, spec)?;
if participants if participants.iter().any(|i| *i == validator_index) {
.iter()
.find(|i| **i == validator_index)
.is_some()
{
included_attestations.push(i); included_attestations.push(i);
} }
} }

View File

@ -13,9 +13,10 @@ use crate::test_utils::TestRandom;
use rand::RngCore; use rand::RngCore;
use serde_derive::Serialize; use serde_derive::Serialize;
use slog; use slog;
use ssz::{hash, Decodable, DecodeError, Encodable, SszStream, TreeHash}; use ssz::{hash, ssz_encode, Decodable, DecodeError, Encodable, SszStream, TreeHash};
use std::cmp::{Ord, Ordering}; use std::cmp::{Ord, Ordering};
use std::fmt; use std::fmt;
use std::hash::{Hash, Hasher};
use std::iter::Iterator; use std::iter::Iterator;
use std::ops::{Add, AddAssign, Div, DivAssign, Mul, MulAssign, Rem, Sub, SubAssign}; use std::ops::{Add, AddAssign, Div, DivAssign, Mul, MulAssign, Rem, Sub, SubAssign};
@ -243,6 +244,18 @@ macro_rules! impl_ssz {
}; };
} }
macro_rules! impl_hash {
($type: ident) => {
// Implemented to stop clippy lint:
// https://rust-lang.github.io/rust-clippy/master/index.html#derive_hash_xor_eq
impl Hash for $type {
fn hash<H: Hasher>(&self, state: &mut H) {
ssz_encode(self).hash(state)
}
}
};
}
macro_rules! impl_common { macro_rules! impl_common {
($type: ident) => { ($type: ident) => {
impl_from_into_u64!($type); impl_from_into_u64!($type);
@ -252,13 +265,14 @@ macro_rules! impl_common {
impl_math!($type); impl_math!($type);
impl_display!($type); impl_display!($type);
impl_ssz!($type); impl_ssz!($type);
impl_hash!($type);
}; };
} }
#[derive(Eq, Debug, Clone, Copy, Default, Serialize, Hash)] #[derive(Eq, Debug, Clone, Copy, Default, Serialize)]
pub struct Slot(u64); pub struct Slot(u64);
#[derive(Eq, Debug, Clone, Copy, Default, Serialize, Hash)] #[derive(Eq, Debug, Clone, Copy, Default, Serialize)]
pub struct Epoch(u64); pub struct Epoch(u64);
impl_common!(Slot); impl_common!(Slot);
@ -269,7 +283,7 @@ impl Slot {
Slot(slot) Slot(slot)
} }
pub fn epoch(&self, epoch_length: u64) -> Epoch { pub fn epoch(self, epoch_length: u64) -> Epoch {
Epoch::from(self.0 / epoch_length) Epoch::from(self.0 / epoch_length)
} }
@ -287,11 +301,11 @@ impl Epoch {
Epoch(u64::max_value()) Epoch(u64::max_value())
} }
pub fn start_slot(&self, epoch_length: u64) -> Slot { pub fn start_slot(self, epoch_length: u64) -> Slot {
Slot::from(self.0.saturating_mul(epoch_length)) Slot::from(self.0.saturating_mul(epoch_length))
} }
pub fn end_slot(&self, epoch_length: u64) -> Slot { pub fn end_slot(self, epoch_length: u64) -> Slot {
Slot::from( Slot::from(
self.0 self.0
.saturating_add(1) .saturating_add(1)

View File

@ -78,7 +78,7 @@ impl Default for Validator {
impl<T: RngCore> TestRandom<T> for StatusFlags { impl<T: RngCore> TestRandom<T> for StatusFlags {
fn random_for_test(rng: &mut T) -> Self { fn random_for_test(rng: &mut T) -> Self {
let options = vec![StatusFlags::InitiatedExit, StatusFlags::Withdrawable]; let options = vec![StatusFlags::InitiatedExit, StatusFlags::Withdrawable];
options[(rng.next_u32() as usize) % options.len()].clone() options[(rng.next_u32() as usize) % options.len()]
} }
} }
@ -130,7 +130,7 @@ impl TreeHash for Validator {
result.append(&mut self.exit_epoch.hash_tree_root()); result.append(&mut self.exit_epoch.hash_tree_root());
result.append(&mut self.withdrawal_epoch.hash_tree_root()); result.append(&mut self.withdrawal_epoch.hash_tree_root());
result.append(&mut self.penalized_epoch.hash_tree_root()); result.append(&mut self.penalized_epoch.hash_tree_root());
result.append(&mut (status_flag_to_byte(self.status_flags) as u64).hash_tree_root()); result.append(&mut u64::from(status_flag_to_byte(self.status_flags)).hash_tree_root());
hash(&result) hash(&result)
} }
} }

View File

@ -5,7 +5,7 @@ use protos::services::{
use protos::services_grpc::BeaconBlockServiceClient; use protos::services_grpc::BeaconBlockServiceClient;
use ssz::{ssz_encode, Decodable}; use ssz::{ssz_encode, Decodable};
use std::sync::Arc; use std::sync::Arc;
use types::{BeaconBlock, BeaconBlockBody, Eth1Data, Hash256, PublicKey, Signature, Slot}; use types::{BeaconBlock, BeaconBlockBody, Eth1Data, Hash256, Signature, Slot};
/// A newtype designed to wrap the gRPC-generated service so the `BeaconNode` trait may be /// A newtype designed to wrap the gRPC-generated service so the `BeaconNode` trait may be
/// implemented upon it. /// implemented upon it.
@ -27,7 +27,8 @@ impl BeaconNode for BeaconBlockGrpcClient {
fn produce_beacon_block( fn produce_beacon_block(
&self, &self,
slot: Slot, slot: Slot,
randao_reveal: &Signature, // TODO: use randao_reveal, when proto APIs have been updated.
_randao_reveal: &Signature,
) -> Result<Option<BeaconBlock>, BeaconNodeError> { ) -> Result<Option<BeaconBlock>, BeaconNodeError> {
let mut req = ProduceBeaconBlockRequest::new(); let mut req = ProduceBeaconBlockRequest::new();
req.set_slot(slot.as_u64()); req.set_slot(slot.as_u64());

View File

@ -1,53 +0,0 @@
use block_producer::{
BeaconNode, BlockProducer, DutiesReader, PollOutcome as BlockProducerPollOutcome, Signer,
};
use slog::{error, info, warn, Logger};
use slot_clock::SlotClock;
use std::time::Duration;
pub struct BlockProducerService<T: SlotClock, U: BeaconNode, V: DutiesReader, W: Signer> {
pub block_producer: BlockProducer<T, U, V, W>,
pub poll_interval_millis: u64,
pub log: Logger,
}
impl<T: SlotClock, U: BeaconNode, V: DutiesReader, W: Signer> BlockProducerService<T, U, V, W> {
/// Run a loop which polls the block producer each `poll_interval_millis` millseconds.
///
/// Logs the results of the polls.
pub fn run(&mut self) {
loop {
match self.block_producer.poll() {
Err(error) => {
error!(self.log, "Block producer poll error"; "error" => format!("{:?}", error))
}
Ok(BlockProducerPollOutcome::BlockProduced(slot)) => {
info!(self.log, "Produced block"; "slot" => slot)
}
Ok(BlockProducerPollOutcome::SlashableBlockNotProduced(slot)) => {
warn!(self.log, "Slashable block was not signed"; "slot" => slot)
}
Ok(BlockProducerPollOutcome::BlockProductionNotRequired(slot)) => {
info!(self.log, "Block production not required"; "slot" => slot)
}
Ok(BlockProducerPollOutcome::ProducerDutiesUnknown(slot)) => {
error!(self.log, "Block production duties unknown"; "slot" => slot)
}
Ok(BlockProducerPollOutcome::SlotAlreadyProcessed(slot)) => {
warn!(self.log, "Attempted to re-process slot"; "slot" => slot)
}
Ok(BlockProducerPollOutcome::BeaconNodeUnableToProduceBlock(slot)) => {
error!(self.log, "Beacon node unable to produce block"; "slot" => slot)
}
Ok(BlockProducerPollOutcome::SignerRejection(slot)) => {
error!(self.log, "The cryptographic signer refused to sign the block"; "slot" => slot)
}
Ok(BlockProducerPollOutcome::ValidatorIsUnknown(slot)) => {
error!(self.log, "The Beacon Node does not recognise the validator"; "slot" => slot)
}
};
std::thread::sleep(Duration::from_millis(self.poll_interval_millis));
}
}
}

View File

@ -1,5 +1,58 @@
mod beacon_block_grpc_client; mod beacon_block_grpc_client;
mod block_producer_service; // mod block_producer_service;
use block_producer::{
BeaconNode, BlockProducer, DutiesReader, PollOutcome as BlockProducerPollOutcome, Signer,
};
use slog::{error, info, warn, Logger};
use slot_clock::SlotClock;
use std::time::Duration;
pub use self::beacon_block_grpc_client::BeaconBlockGrpcClient; pub use self::beacon_block_grpc_client::BeaconBlockGrpcClient;
pub use self::block_producer_service::BlockProducerService;
pub struct BlockProducerService<T: SlotClock, U: BeaconNode, V: DutiesReader, W: Signer> {
pub block_producer: BlockProducer<T, U, V, W>,
pub poll_interval_millis: u64,
pub log: Logger,
}
impl<T: SlotClock, U: BeaconNode, V: DutiesReader, W: Signer> BlockProducerService<T, U, V, W> {
/// Run a loop which polls the block producer each `poll_interval_millis` millseconds.
///
/// Logs the results of the polls.
pub fn run(&mut self) {
loop {
match self.block_producer.poll() {
Err(error) => {
error!(self.log, "Block producer poll error"; "error" => format!("{:?}", error))
}
Ok(BlockProducerPollOutcome::BlockProduced(slot)) => {
info!(self.log, "Produced block"; "slot" => slot)
}
Ok(BlockProducerPollOutcome::SlashableBlockNotProduced(slot)) => {
warn!(self.log, "Slashable block was not signed"; "slot" => slot)
}
Ok(BlockProducerPollOutcome::BlockProductionNotRequired(slot)) => {
info!(self.log, "Block production not required"; "slot" => slot)
}
Ok(BlockProducerPollOutcome::ProducerDutiesUnknown(slot)) => {
error!(self.log, "Block production duties unknown"; "slot" => slot)
}
Ok(BlockProducerPollOutcome::SlotAlreadyProcessed(slot)) => {
warn!(self.log, "Attempted to re-process slot"; "slot" => slot)
}
Ok(BlockProducerPollOutcome::BeaconNodeUnableToProduceBlock(slot)) => {
error!(self.log, "Beacon node unable to produce block"; "slot" => slot)
}
Ok(BlockProducerPollOutcome::SignerRejection(slot)) => {
error!(self.log, "The cryptographic signer refused to sign the block"; "slot" => slot)
}
Ok(BlockProducerPollOutcome::ValidatorIsUnknown(slot)) => {
error!(self.log, "The Beacon Node does not recognise the validator"; "slot" => slot)
}
};
std::thread::sleep(Duration::from_millis(self.poll_interval_millis));
}
}
}

View File

@ -47,7 +47,7 @@ impl EpochDutiesMap {
pub fn get(&self, epoch: Epoch) -> Result<Option<EpochDuties>, EpochDutiesMapError> { pub fn get(&self, epoch: Epoch) -> Result<Option<EpochDuties>, EpochDutiesMapError> {
let map = self.map.read().map_err(|_| EpochDutiesMapError::Poisoned)?; let map = self.map.read().map_err(|_| EpochDutiesMapError::Poisoned)?;
match map.get(&epoch) { match map.get(&epoch) {
Some(duties) => Ok(Some(duties.clone())), Some(duties) => Ok(Some(*duties)),
None => Ok(None), None => Ok(None),
} }
} }

View File

@ -12,7 +12,7 @@ use self::traits::{BeaconNode, BeaconNodeError};
use bls::PublicKey; use bls::PublicKey;
use slot_clock::SlotClock; use slot_clock::SlotClock;
use std::sync::Arc; use std::sync::Arc;
use types::{ChainSpec, Epoch, Slot}; use types::{ChainSpec, Epoch};
#[derive(Debug, PartialEq, Clone, Copy)] #[derive(Debug, PartialEq, Clone, Copy)]
pub enum PollOutcome { pub enum PollOutcome {
@ -33,7 +33,6 @@ pub enum Error {
SlotClockError, SlotClockError,
SlotUnknowable, SlotUnknowable,
EpochMapPoisoned, EpochMapPoisoned,
EpochLengthIsZero,
BeaconNodeError(BeaconNodeError), BeaconNodeError(BeaconNodeError),
} }
@ -103,6 +102,7 @@ mod tests {
use super::*; use super::*;
use bls::Keypair; use bls::Keypair;
use slot_clock::TestingSlotClock; use slot_clock::TestingSlotClock;
use types::Slot;
// TODO: implement more thorough testing. // TODO: implement more thorough testing.
// https://github.com/sigp/lighthouse/issues/160 // https://github.com/sigp/lighthouse/issues/160