Update network
and rpc
to BeaconStateTypes
This commit is contained in:
parent
51dc97ee42
commit
42b7aa89d4
@ -8,19 +8,22 @@ use beacon_chain::{
|
|||||||
AttestationValidationError, CheckPoint,
|
AttestationValidationError, CheckPoint,
|
||||||
};
|
};
|
||||||
use eth2_libp2p::rpc::HelloMessage;
|
use eth2_libp2p::rpc::HelloMessage;
|
||||||
use types::{Attestation, BeaconBlock, BeaconBlockBody, BeaconBlockHeader, Epoch, Hash256, Slot};
|
use types::{
|
||||||
|
Attestation, BeaconBlock, BeaconBlockBody, BeaconBlockHeader, BeaconStateTypes, Epoch, Hash256,
|
||||||
|
Slot,
|
||||||
|
};
|
||||||
|
|
||||||
pub use beacon_chain::{BeaconChainError, BlockProcessingOutcome, InvalidBlock};
|
pub use beacon_chain::{BeaconChainError, BlockProcessingOutcome, InvalidBlock};
|
||||||
|
|
||||||
/// The network's API to the beacon chain.
|
/// The network's API to the beacon chain.
|
||||||
pub trait BeaconChain: Send + Sync {
|
pub trait BeaconChain<B: BeaconStateTypes>: Send + Sync {
|
||||||
fn get_spec(&self) -> &ChainSpec;
|
fn get_spec(&self) -> &ChainSpec;
|
||||||
|
|
||||||
fn get_state(&self) -> RwLockReadGuard<BeaconState>;
|
fn get_state(&self) -> RwLockReadGuard<BeaconState<B>>;
|
||||||
|
|
||||||
fn slot(&self) -> Slot;
|
fn slot(&self) -> Slot;
|
||||||
|
|
||||||
fn head(&self) -> RwLockReadGuard<CheckPoint>;
|
fn head(&self) -> RwLockReadGuard<CheckPoint<B>>;
|
||||||
|
|
||||||
fn get_block(&self, block_root: &Hash256) -> Result<Option<BeaconBlock>, BeaconChainError>;
|
fn get_block(&self, block_root: &Hash256) -> Result<Option<BeaconBlock>, BeaconChainError>;
|
||||||
|
|
||||||
@ -28,7 +31,7 @@ pub trait BeaconChain: Send + Sync {
|
|||||||
|
|
||||||
fn best_block_root(&self) -> Hash256;
|
fn best_block_root(&self) -> Hash256;
|
||||||
|
|
||||||
fn finalized_head(&self) -> RwLockReadGuard<CheckPoint>;
|
fn finalized_head(&self) -> RwLockReadGuard<CheckPoint<B>>;
|
||||||
|
|
||||||
fn finalized_epoch(&self) -> Epoch;
|
fn finalized_epoch(&self) -> Epoch;
|
||||||
|
|
||||||
@ -62,17 +65,18 @@ pub trait BeaconChain: Send + Sync {
|
|||||||
fn is_new_block_root(&self, beacon_block_root: &Hash256) -> Result<bool, BeaconChainError>;
|
fn is_new_block_root(&self, beacon_block_root: &Hash256) -> Result<bool, BeaconChainError>;
|
||||||
}
|
}
|
||||||
|
|
||||||
impl<T, U, F> BeaconChain for RawBeaconChain<T, U, F>
|
impl<T, U, F, B> BeaconChain<B> for RawBeaconChain<T, U, F, B>
|
||||||
where
|
where
|
||||||
T: ClientDB + Sized,
|
T: ClientDB + Sized,
|
||||||
U: SlotClock,
|
U: SlotClock,
|
||||||
F: ForkChoice,
|
F: ForkChoice,
|
||||||
|
B: BeaconStateTypes,
|
||||||
{
|
{
|
||||||
fn get_spec(&self) -> &ChainSpec {
|
fn get_spec(&self) -> &ChainSpec {
|
||||||
&self.spec
|
&self.spec
|
||||||
}
|
}
|
||||||
|
|
||||||
fn get_state(&self) -> RwLockReadGuard<BeaconState> {
|
fn get_state(&self) -> RwLockReadGuard<BeaconState<B>> {
|
||||||
self.state.read()
|
self.state.read()
|
||||||
}
|
}
|
||||||
|
|
||||||
@ -80,7 +84,7 @@ where
|
|||||||
self.get_state().slot
|
self.get_state().slot
|
||||||
}
|
}
|
||||||
|
|
||||||
fn head(&self) -> RwLockReadGuard<CheckPoint> {
|
fn head(&self) -> RwLockReadGuard<CheckPoint<B>> {
|
||||||
self.head()
|
self.head()
|
||||||
}
|
}
|
||||||
|
|
||||||
@ -92,7 +96,7 @@ where
|
|||||||
self.get_state().finalized_epoch
|
self.get_state().finalized_epoch
|
||||||
}
|
}
|
||||||
|
|
||||||
fn finalized_head(&self) -> RwLockReadGuard<CheckPoint> {
|
fn finalized_head(&self) -> RwLockReadGuard<CheckPoint<B>> {
|
||||||
self.finalized_head()
|
self.finalized_head()
|
||||||
}
|
}
|
||||||
|
|
||||||
|
@ -13,6 +13,7 @@ use slog::{debug, warn};
|
|||||||
use std::collections::HashMap;
|
use std::collections::HashMap;
|
||||||
use std::sync::Arc;
|
use std::sync::Arc;
|
||||||
use std::time::Instant;
|
use std::time::Instant;
|
||||||
|
use types::BeaconStateTypes;
|
||||||
|
|
||||||
/// Timeout for RPC requests.
|
/// Timeout for RPC requests.
|
||||||
// const REQUEST_TIMEOUT: Duration = Duration::from_secs(30);
|
// const REQUEST_TIMEOUT: Duration = Duration::from_secs(30);
|
||||||
@ -20,11 +21,11 @@ use std::time::Instant;
|
|||||||
// const HELLO_TIMEOUT: Duration = Duration::from_secs(30);
|
// const HELLO_TIMEOUT: Duration = Duration::from_secs(30);
|
||||||
|
|
||||||
/// Handles messages received from the network and client and organises syncing.
|
/// Handles messages received from the network and client and organises syncing.
|
||||||
pub struct MessageHandler {
|
pub struct MessageHandler<B: BeaconStateTypes> {
|
||||||
/// Currently loaded and initialised beacon chain.
|
/// Currently loaded and initialised beacon chain.
|
||||||
_chain: Arc<BeaconChain>,
|
_chain: Arc<BeaconChain<B>>,
|
||||||
/// The syncing framework.
|
/// The syncing framework.
|
||||||
sync: SimpleSync,
|
sync: SimpleSync<B>,
|
||||||
/// The context required to send messages to, and process messages from peers.
|
/// The context required to send messages to, and process messages from peers.
|
||||||
network_context: NetworkContext,
|
network_context: NetworkContext,
|
||||||
/// The `MessageHandler` logger.
|
/// The `MessageHandler` logger.
|
||||||
@ -44,10 +45,10 @@ pub enum HandlerMessage {
|
|||||||
PubsubMessage(PeerId, Box<PubsubMessage>),
|
PubsubMessage(PeerId, Box<PubsubMessage>),
|
||||||
}
|
}
|
||||||
|
|
||||||
impl MessageHandler {
|
impl<B: BeaconStateTypes> MessageHandler<B> {
|
||||||
/// Initializes and runs the MessageHandler.
|
/// Initializes and runs the MessageHandler.
|
||||||
pub fn spawn(
|
pub fn spawn(
|
||||||
beacon_chain: Arc<BeaconChain>,
|
beacon_chain: Arc<BeaconChain<B>>,
|
||||||
network_send: crossbeam_channel::Sender<NetworkMessage>,
|
network_send: crossbeam_channel::Sender<NetworkMessage>,
|
||||||
executor: &tokio::runtime::TaskExecutor,
|
executor: &tokio::runtime::TaskExecutor,
|
||||||
log: slog::Logger,
|
log: slog::Logger,
|
||||||
|
@ -10,22 +10,23 @@ use futures::prelude::*;
|
|||||||
use futures::sync::oneshot;
|
use futures::sync::oneshot;
|
||||||
use futures::Stream;
|
use futures::Stream;
|
||||||
use slog::{debug, info, o, trace};
|
use slog::{debug, info, o, trace};
|
||||||
|
use std::marker::PhantomData;
|
||||||
use std::sync::Arc;
|
use std::sync::Arc;
|
||||||
use tokio::runtime::TaskExecutor;
|
use tokio::runtime::TaskExecutor;
|
||||||
use types::Topic;
|
use types::{BeaconStateTypes, Topic};
|
||||||
|
|
||||||
/// Service that handles communication between internal services and the eth2_libp2p network service.
|
/// Service that handles communication between internal services and the eth2_libp2p network service.
|
||||||
pub struct Service {
|
pub struct Service<B: BeaconStateTypes> {
|
||||||
//libp2p_service: Arc<Mutex<LibP2PService>>,
|
//libp2p_service: Arc<Mutex<LibP2PService>>,
|
||||||
_libp2p_exit: oneshot::Sender<()>,
|
_libp2p_exit: oneshot::Sender<()>,
|
||||||
network_send: crossbeam_channel::Sender<NetworkMessage>,
|
network_send: crossbeam_channel::Sender<NetworkMessage>,
|
||||||
//message_handler: MessageHandler,
|
_phantom: PhantomData<B>, //message_handler: MessageHandler,
|
||||||
//message_handler_send: Sender<HandlerMessage>,
|
//message_handler_send: Sender<HandlerMessage>
|
||||||
}
|
}
|
||||||
|
|
||||||
impl Service {
|
impl<B: BeaconStateTypes> Service<B> {
|
||||||
pub fn new(
|
pub fn new(
|
||||||
beacon_chain: Arc<BeaconChain>,
|
beacon_chain: Arc<BeaconChain<B>>,
|
||||||
config: &NetworkConfig,
|
config: &NetworkConfig,
|
||||||
executor: &TaskExecutor,
|
executor: &TaskExecutor,
|
||||||
log: slog::Logger,
|
log: slog::Logger,
|
||||||
@ -56,6 +57,7 @@ impl Service {
|
|||||||
let network_service = Service {
|
let network_service = Service {
|
||||||
_libp2p_exit: libp2p_exit,
|
_libp2p_exit: libp2p_exit,
|
||||||
network_send: network_send.clone(),
|
network_send: network_send.clone(),
|
||||||
|
_phantom: PhantomData,
|
||||||
};
|
};
|
||||||
|
|
||||||
Ok((Arc::new(network_service), network_send))
|
Ok((Arc::new(network_service), network_send))
|
||||||
|
@ -5,7 +5,7 @@ use slog::{debug, error};
|
|||||||
use std::sync::Arc;
|
use std::sync::Arc;
|
||||||
use std::time::{Duration, Instant};
|
use std::time::{Duration, Instant};
|
||||||
use tree_hash::TreeHash;
|
use tree_hash::TreeHash;
|
||||||
use types::{BeaconBlock, BeaconBlockBody, BeaconBlockHeader, Hash256, Slot};
|
use types::{BeaconBlock, BeaconBlockBody, BeaconBlockHeader, BeaconStateTypes, Hash256, Slot};
|
||||||
|
|
||||||
/// Provides a queue for fully and partially built `BeaconBlock`s.
|
/// Provides a queue for fully and partially built `BeaconBlock`s.
|
||||||
///
|
///
|
||||||
@ -19,8 +19,8 @@ use types::{BeaconBlock, BeaconBlockBody, BeaconBlockHeader, Hash256, Slot};
|
|||||||
/// `BeaconBlockBody` as the key.
|
/// `BeaconBlockBody` as the key.
|
||||||
/// - It is possible for multiple distinct blocks to have identical `BeaconBlockBodies`. Therefore
|
/// - It is possible for multiple distinct blocks to have identical `BeaconBlockBodies`. Therefore
|
||||||
/// we cannot use a `HashMap` keyed by the root of `BeaconBlockBody`.
|
/// we cannot use a `HashMap` keyed by the root of `BeaconBlockBody`.
|
||||||
pub struct ImportQueue {
|
pub struct ImportQueue<B: BeaconStateTypes> {
|
||||||
pub chain: Arc<BeaconChain>,
|
pub chain: Arc<BeaconChain<B>>,
|
||||||
/// Partially imported blocks, keyed by the root of `BeaconBlockBody`.
|
/// Partially imported blocks, keyed by the root of `BeaconBlockBody`.
|
||||||
pub partials: Vec<PartialBeaconBlock>,
|
pub partials: Vec<PartialBeaconBlock>,
|
||||||
/// Time before a queue entry is considered state.
|
/// Time before a queue entry is considered state.
|
||||||
@ -29,9 +29,9 @@ pub struct ImportQueue {
|
|||||||
log: slog::Logger,
|
log: slog::Logger,
|
||||||
}
|
}
|
||||||
|
|
||||||
impl ImportQueue {
|
impl<B: BeaconStateTypes> ImportQueue<B> {
|
||||||
/// Return a new, empty queue.
|
/// Return a new, empty queue.
|
||||||
pub fn new(chain: Arc<BeaconChain>, stale_time: Duration, log: slog::Logger) -> Self {
|
pub fn new(chain: Arc<BeaconChain<B>>, stale_time: Duration, log: slog::Logger) -> Self {
|
||||||
Self {
|
Self {
|
||||||
chain,
|
chain,
|
||||||
partials: vec![],
|
partials: vec![],
|
||||||
|
@ -9,7 +9,7 @@ use std::collections::HashMap;
|
|||||||
use std::sync::Arc;
|
use std::sync::Arc;
|
||||||
use std::time::Duration;
|
use std::time::Duration;
|
||||||
use tree_hash::TreeHash;
|
use tree_hash::TreeHash;
|
||||||
use types::{Attestation, BeaconBlock, Epoch, Hash256, Slot};
|
use types::{Attestation, BeaconBlock, BeaconStateTypes, Epoch, Hash256, Slot};
|
||||||
|
|
||||||
/// The number of slots that we can import blocks ahead of us, before going into full Sync mode.
|
/// The number of slots that we can import blocks ahead of us, before going into full Sync mode.
|
||||||
const SLOT_IMPORT_TOLERANCE: u64 = 100;
|
const SLOT_IMPORT_TOLERANCE: u64 = 100;
|
||||||
@ -88,8 +88,8 @@ impl From<HelloMessage> for PeerSyncInfo {
|
|||||||
}
|
}
|
||||||
}
|
}
|
||||||
|
|
||||||
impl From<&Arc<BeaconChain>> for PeerSyncInfo {
|
impl<B: BeaconStateTypes> From<&Arc<BeaconChain<B>>> for PeerSyncInfo {
|
||||||
fn from(chain: &Arc<BeaconChain>) -> PeerSyncInfo {
|
fn from(chain: &Arc<BeaconChain<B>>) -> PeerSyncInfo {
|
||||||
Self::from(chain.hello_message())
|
Self::from(chain.hello_message())
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
@ -103,22 +103,22 @@ pub enum SyncState {
|
|||||||
}
|
}
|
||||||
|
|
||||||
/// Simple Syncing protocol.
|
/// Simple Syncing protocol.
|
||||||
pub struct SimpleSync {
|
pub struct SimpleSync<B: BeaconStateTypes> {
|
||||||
/// A reference to the underlying beacon chain.
|
/// A reference to the underlying beacon chain.
|
||||||
chain: Arc<BeaconChain>,
|
chain: Arc<BeaconChain<B>>,
|
||||||
/// A mapping of Peers to their respective PeerSyncInfo.
|
/// A mapping of Peers to their respective PeerSyncInfo.
|
||||||
known_peers: HashMap<PeerId, PeerSyncInfo>,
|
known_peers: HashMap<PeerId, PeerSyncInfo>,
|
||||||
/// A queue to allow importing of blocks
|
/// A queue to allow importing of blocks
|
||||||
import_queue: ImportQueue,
|
import_queue: ImportQueue<B>,
|
||||||
/// The current state of the syncing protocol.
|
/// The current state of the syncing protocol.
|
||||||
state: SyncState,
|
state: SyncState,
|
||||||
/// Sync logger.
|
/// Sync logger.
|
||||||
log: slog::Logger,
|
log: slog::Logger,
|
||||||
}
|
}
|
||||||
|
|
||||||
impl SimpleSync {
|
impl<B: BeaconStateTypes> SimpleSync<B> {
|
||||||
/// Instantiate a `SimpleSync` instance, with no peers and an empty queue.
|
/// Instantiate a `SimpleSync` instance, with no peers and an empty queue.
|
||||||
pub fn new(beacon_chain: Arc<BeaconChain>, log: &slog::Logger) -> Self {
|
pub fn new(beacon_chain: Arc<BeaconChain<B>>, log: &slog::Logger) -> Self {
|
||||||
let sync_logger = log.new(o!("Service"=> "Sync"));
|
let sync_logger = log.new(o!("Service"=> "Sync"));
|
||||||
|
|
||||||
let queue_item_stale_time = Duration::from_secs(QUEUE_STALE_SECS);
|
let queue_item_stale_time = Duration::from_secs(QUEUE_STALE_SECS);
|
||||||
|
@ -9,15 +9,15 @@ use protos::services_grpc::AttestationService;
|
|||||||
use slog::{error, info, trace, warn};
|
use slog::{error, info, trace, warn};
|
||||||
use ssz::{ssz_encode, Decodable};
|
use ssz::{ssz_encode, Decodable};
|
||||||
use std::sync::Arc;
|
use std::sync::Arc;
|
||||||
use types::Attestation;
|
use types::{Attestation, BeaconStateTypes};
|
||||||
|
|
||||||
#[derive(Clone)]
|
#[derive(Clone)]
|
||||||
pub struct AttestationServiceInstance {
|
pub struct AttestationServiceInstance<B: BeaconStateTypes> {
|
||||||
pub chain: Arc<BeaconChain>,
|
pub chain: Arc<BeaconChain<B>>,
|
||||||
pub log: slog::Logger,
|
pub log: slog::Logger,
|
||||||
}
|
}
|
||||||
|
|
||||||
impl AttestationService for AttestationServiceInstance {
|
impl<B: BeaconStateTypes> AttestationService for AttestationServiceInstance<B> {
|
||||||
/// Produce the `AttestationData` for signing by a validator.
|
/// Produce the `AttestationData` for signing by a validator.
|
||||||
fn produce_attestation_data(
|
fn produce_attestation_data(
|
||||||
&mut self,
|
&mut self,
|
||||||
|
@ -13,16 +13,16 @@ use slog::Logger;
|
|||||||
use slog::{error, info, trace, warn};
|
use slog::{error, info, trace, warn};
|
||||||
use ssz::{ssz_encode, Decodable};
|
use ssz::{ssz_encode, Decodable};
|
||||||
use std::sync::Arc;
|
use std::sync::Arc;
|
||||||
use types::{BeaconBlock, Signature, Slot};
|
use types::{BeaconBlock, BeaconStateTypes, Signature, Slot};
|
||||||
|
|
||||||
#[derive(Clone)]
|
#[derive(Clone)]
|
||||||
pub struct BeaconBlockServiceInstance {
|
pub struct BeaconBlockServiceInstance<B: BeaconStateTypes> {
|
||||||
pub chain: Arc<BeaconChain>,
|
pub chain: Arc<BeaconChain<B>>,
|
||||||
pub network_chan: crossbeam_channel::Sender<NetworkMessage>,
|
pub network_chan: crossbeam_channel::Sender<NetworkMessage>,
|
||||||
pub log: Logger,
|
pub log: Logger,
|
||||||
}
|
}
|
||||||
|
|
||||||
impl BeaconBlockService for BeaconBlockServiceInstance {
|
impl<B: BeaconStateTypes> BeaconBlockService for BeaconBlockServiceInstance<B> {
|
||||||
/// Produce a `BeaconBlock` for signing by a validator.
|
/// Produce a `BeaconBlock` for signing by a validator.
|
||||||
fn produce_beacon_block(
|
fn produce_beacon_block(
|
||||||
&mut self,
|
&mut self,
|
||||||
|
@ -8,15 +8,15 @@ use beacon_chain::{
|
|||||||
AttestationValidationError, BlockProductionError,
|
AttestationValidationError, BlockProductionError,
|
||||||
};
|
};
|
||||||
pub use beacon_chain::{BeaconChainError, BlockProcessingOutcome};
|
pub use beacon_chain::{BeaconChainError, BlockProcessingOutcome};
|
||||||
use types::{Attestation, AttestationData, BeaconBlock};
|
use types::{Attestation, AttestationData, BeaconBlock, BeaconStateTypes};
|
||||||
|
|
||||||
/// The RPC's API to the beacon chain.
|
/// The RPC's API to the beacon chain.
|
||||||
pub trait BeaconChain: Send + Sync {
|
pub trait BeaconChain<B: BeaconStateTypes>: Send + Sync {
|
||||||
fn get_spec(&self) -> &ChainSpec;
|
fn get_spec(&self) -> &ChainSpec;
|
||||||
|
|
||||||
fn get_state(&self) -> RwLockReadGuard<BeaconState>;
|
fn get_state(&self) -> RwLockReadGuard<BeaconState<B>>;
|
||||||
|
|
||||||
fn get_mut_state(&self) -> RwLockWriteGuard<BeaconState>;
|
fn get_mut_state(&self) -> RwLockWriteGuard<BeaconState<B>>;
|
||||||
|
|
||||||
fn process_block(&self, block: BeaconBlock)
|
fn process_block(&self, block: BeaconBlock)
|
||||||
-> Result<BlockProcessingOutcome, BeaconChainError>;
|
-> Result<BlockProcessingOutcome, BeaconChainError>;
|
||||||
@ -24,7 +24,7 @@ pub trait BeaconChain: Send + Sync {
|
|||||||
fn produce_block(
|
fn produce_block(
|
||||||
&self,
|
&self,
|
||||||
randao_reveal: Signature,
|
randao_reveal: Signature,
|
||||||
) -> Result<(BeaconBlock, BeaconState), BlockProductionError>;
|
) -> Result<(BeaconBlock, BeaconState<B>), BlockProductionError>;
|
||||||
|
|
||||||
fn produce_attestation_data(&self, shard: u64) -> Result<AttestationData, BeaconChainError>;
|
fn produce_attestation_data(&self, shard: u64) -> Result<AttestationData, BeaconChainError>;
|
||||||
|
|
||||||
@ -34,21 +34,22 @@ pub trait BeaconChain: Send + Sync {
|
|||||||
) -> Result<(), AttestationValidationError>;
|
) -> Result<(), AttestationValidationError>;
|
||||||
}
|
}
|
||||||
|
|
||||||
impl<T, U, F> BeaconChain for RawBeaconChain<T, U, F>
|
impl<T, U, F, B> BeaconChain<B> for RawBeaconChain<T, U, F, B>
|
||||||
where
|
where
|
||||||
T: ClientDB + Sized,
|
T: ClientDB + Sized,
|
||||||
U: SlotClock,
|
U: SlotClock,
|
||||||
F: ForkChoice,
|
F: ForkChoice,
|
||||||
|
B: BeaconStateTypes,
|
||||||
{
|
{
|
||||||
fn get_spec(&self) -> &ChainSpec {
|
fn get_spec(&self) -> &ChainSpec {
|
||||||
&self.spec
|
&self.spec
|
||||||
}
|
}
|
||||||
|
|
||||||
fn get_state(&self) -> RwLockReadGuard<BeaconState> {
|
fn get_state(&self) -> RwLockReadGuard<BeaconState<B>> {
|
||||||
self.state.read()
|
self.state.read()
|
||||||
}
|
}
|
||||||
|
|
||||||
fn get_mut_state(&self) -> RwLockWriteGuard<BeaconState> {
|
fn get_mut_state(&self) -> RwLockWriteGuard<BeaconState<B>> {
|
||||||
self.state.write()
|
self.state.write()
|
||||||
}
|
}
|
||||||
|
|
||||||
@ -62,7 +63,7 @@ where
|
|||||||
fn produce_block(
|
fn produce_block(
|
||||||
&self,
|
&self,
|
||||||
randao_reveal: Signature,
|
randao_reveal: Signature,
|
||||||
) -> Result<(BeaconBlock, BeaconState), BlockProductionError> {
|
) -> Result<(BeaconBlock, BeaconState<B>), BlockProductionError> {
|
||||||
self.produce_block(randao_reveal)
|
self.produce_block(randao_reveal)
|
||||||
}
|
}
|
||||||
|
|
||||||
|
@ -5,14 +5,15 @@ use protos::services::{Empty, Fork, NodeInfoResponse};
|
|||||||
use protos::services_grpc::BeaconNodeService;
|
use protos::services_grpc::BeaconNodeService;
|
||||||
use slog::{trace, warn};
|
use slog::{trace, warn};
|
||||||
use std::sync::Arc;
|
use std::sync::Arc;
|
||||||
|
use types::BeaconStateTypes;
|
||||||
|
|
||||||
#[derive(Clone)]
|
#[derive(Clone)]
|
||||||
pub struct BeaconNodeServiceInstance {
|
pub struct BeaconNodeServiceInstance<B: BeaconStateTypes> {
|
||||||
pub chain: Arc<BeaconChain>,
|
pub chain: Arc<BeaconChain<B>>,
|
||||||
pub log: slog::Logger,
|
pub log: slog::Logger,
|
||||||
}
|
}
|
||||||
|
|
||||||
impl BeaconNodeService for BeaconNodeServiceInstance {
|
impl<B: BeaconStateTypes> BeaconNodeService for BeaconNodeServiceInstance<B> {
|
||||||
/// Provides basic node information.
|
/// Provides basic node information.
|
||||||
fn info(&mut self, ctx: RpcContext, _req: Empty, sink: UnarySink<NodeInfoResponse>) {
|
fn info(&mut self, ctx: RpcContext, _req: Empty, sink: UnarySink<NodeInfoResponse>) {
|
||||||
trace!(self.log, "Node info requested via RPC");
|
trace!(self.log, "Node info requested via RPC");
|
||||||
|
@ -21,12 +21,13 @@ use protos::services_grpc::{
|
|||||||
use slog::{info, o, warn};
|
use slog::{info, o, warn};
|
||||||
use std::sync::Arc;
|
use std::sync::Arc;
|
||||||
use tokio::runtime::TaskExecutor;
|
use tokio::runtime::TaskExecutor;
|
||||||
|
use types::BeaconStateTypes;
|
||||||
|
|
||||||
pub fn start_server(
|
pub fn start_server<B: BeaconStateTypes>(
|
||||||
config: &RPCConfig,
|
config: &RPCConfig,
|
||||||
executor: &TaskExecutor,
|
executor: &TaskExecutor,
|
||||||
network_chan: crossbeam_channel::Sender<NetworkMessage>,
|
network_chan: crossbeam_channel::Sender<NetworkMessage>,
|
||||||
beacon_chain: Arc<BeaconChain>,
|
beacon_chain: Arc<BeaconChain<B>>,
|
||||||
log: &slog::Logger,
|
log: &slog::Logger,
|
||||||
) -> exit_future::Signal {
|
) -> exit_future::Signal {
|
||||||
let log = log.new(o!("Service"=>"RPC"));
|
let log = log.new(o!("Service"=>"RPC"));
|
||||||
|
@ -7,16 +7,16 @@ use protos::services_grpc::ValidatorService;
|
|||||||
use slog::{trace, warn};
|
use slog::{trace, warn};
|
||||||
use ssz::decode;
|
use ssz::decode;
|
||||||
use std::sync::Arc;
|
use std::sync::Arc;
|
||||||
use types::{Epoch, RelativeEpoch};
|
use types::{BeaconStateTypes, Epoch, RelativeEpoch};
|
||||||
|
|
||||||
#[derive(Clone)]
|
#[derive(Clone)]
|
||||||
pub struct ValidatorServiceInstance {
|
pub struct ValidatorServiceInstance<B: BeaconStateTypes> {
|
||||||
pub chain: Arc<BeaconChain>,
|
pub chain: Arc<BeaconChain<B>>,
|
||||||
pub log: slog::Logger,
|
pub log: slog::Logger,
|
||||||
}
|
}
|
||||||
//TODO: Refactor Errors
|
//TODO: Refactor Errors
|
||||||
|
|
||||||
impl ValidatorService for ValidatorServiceInstance {
|
impl<B: BeaconStateTypes> ValidatorService for ValidatorServiceInstance<B> {
|
||||||
/// For a list of validator public keys, this function returns the slot at which each
|
/// For a list of validator public keys, this function returns the slot at which each
|
||||||
/// validator must propose a block, attest to a shard, their shard committee and the shard they
|
/// validator must propose a block, attest to a shard, their shard committee and the shard they
|
||||||
/// need to attest to.
|
/// need to attest to.
|
||||||
|
@ -2,7 +2,7 @@ use crate::*;
|
|||||||
use fixed_len_vec::typenum::{Unsigned, U1024, U8, U8192};
|
use fixed_len_vec::typenum::{Unsigned, U1024, U8, U8192};
|
||||||
use std::fmt::Debug;
|
use std::fmt::Debug;
|
||||||
|
|
||||||
pub trait BeaconStateTypes: Default + Sync + Send + Clone + Debug + PartialEq {
|
pub trait BeaconStateTypes: 'static + Default + Sync + Send + Clone + Debug + PartialEq {
|
||||||
type ShardCount: Unsigned + Clone + Sync + Send + Debug + PartialEq;
|
type ShardCount: Unsigned + Clone + Sync + Send + Debug + PartialEq;
|
||||||
type SlotsPerHistoricalRoot: Unsigned + Clone + Sync + Send + Debug + PartialEq;
|
type SlotsPerHistoricalRoot: Unsigned + Clone + Sync + Send + Debug + PartialEq;
|
||||||
type LatestRandaoMixesLength: Unsigned + Clone + Sync + Send + Debug + PartialEq;
|
type LatestRandaoMixesLength: Unsigned + Clone + Sync + Send + Debug + PartialEq;
|
||||||
|
Loading…
Reference in New Issue
Block a user