Restrict network limits based on merge fork epoch (#2839)

This commit is contained in:
Pawan Dhananjay 2021-12-01 20:00:39 -06:00 committed by Paul Hauner
parent 144978f8f8
commit f3c237cfa0
No known key found for this signature in database
GPG Key ID: 5E2CFF9B75FA63DF
12 changed files with 57 additions and 66 deletions

View File

@ -16,8 +16,10 @@ use std::sync::Arc;
use std::time::Duration; use std::time::Duration;
use types::{ForkContext, ForkName}; use types::{ForkContext, ForkName};
/// The maximum transmit size of gossip messages in bytes. /// The maximum transmit size of gossip messages in bytes pre-merge.
pub const GOSSIP_MAX_SIZE: usize = 10 * 1_048_576; // 10M const GOSSIP_MAX_SIZE: usize = 1_048_576; // 1M
/// The maximum transmit size of gossip messages in bytes post-merge.
const GOSSIP_MAX_SIZE_POST_MERGE: usize = 10 * 1_048_576; // 10M
/// This is a constant to be used in discovery. The lower bound of the gossipsub mesh. /// This is a constant to be used in discovery. The lower bound of the gossipsub mesh.
pub const MESH_N_LOW: usize = 6; pub const MESH_N_LOW: usize = 6;
@ -40,6 +42,15 @@ pub const DUPLICATE_CACHE_TIME: Duration = Duration::from_secs(33 * 12 + 1);
// const MESSAGE_DOMAIN_INVALID_SNAPPY: [u8; 4] = [0, 0, 0, 0]; // const MESSAGE_DOMAIN_INVALID_SNAPPY: [u8; 4] = [0, 0, 0, 0];
const MESSAGE_DOMAIN_VALID_SNAPPY: [u8; 4] = [1, 0, 0, 0]; const MESSAGE_DOMAIN_VALID_SNAPPY: [u8; 4] = [1, 0, 0, 0];
/// The maximum size of gossip messages.
pub fn gossip_max_size(is_merge_enabled: bool) -> usize {
if is_merge_enabled {
GOSSIP_MAX_SIZE_POST_MERGE
} else {
GOSSIP_MAX_SIZE
}
}
#[derive(Clone, Debug, Serialize, Deserialize)] #[derive(Clone, Debug, Serialize, Deserialize)]
#[serde(default)] #[serde(default)]
/// Network configuration for lighthouse. /// Network configuration for lighthouse.
@ -231,6 +242,7 @@ pub fn gossipsub_config(fork_context: Arc<ForkContext>) -> GossipsubConfig {
} }
} }
let is_merge_enabled = fork_context.fork_exists(ForkName::Merge);
let gossip_message_id = move |message: &GossipsubMessage| { let gossip_message_id = move |message: &GossipsubMessage| {
MessageId::from( MessageId::from(
&Sha256::digest( &Sha256::digest(
@ -239,7 +251,7 @@ pub fn gossipsub_config(fork_context: Arc<ForkContext>) -> GossipsubConfig {
) )
}; };
GossipsubConfigBuilder::default() GossipsubConfigBuilder::default()
.max_transmit_size(GOSSIP_MAX_SIZE) .max_transmit_size(gossip_max_size(is_merge_enabled))
.heartbeat_interval(Duration::from_millis(700)) .heartbeat_interval(Duration::from_millis(700))
.mesh_n(8) .mesh_n(8)
.mesh_n_low(MESH_N_LOW) .mesh_n_low(MESH_N_LOW)

View File

@ -16,7 +16,7 @@ pub mod rpc;
mod service; mod service;
pub mod types; pub mod types;
pub use config::GOSSIP_MAX_SIZE; pub use config::gossip_max_size;
use serde::{de, Deserialize, Deserializer, Serialize, Serializer}; use serde::{de, Deserialize, Deserializer, Serialize, Serializer};
use std::str::FromStr; use std::str::FromStr;

View File

@ -697,9 +697,9 @@ mod tests {
version: Version, version: Version,
message: &mut BytesMut, message: &mut BytesMut,
) -> Result<Option<RPCResponse<Spec>>, RPCError> { ) -> Result<Option<RPCResponse<Spec>>, RPCError> {
let max_packet_size = 1_048_576;
let snappy_protocol_id = ProtocolId::new(protocol, version, Encoding::SSZSnappy); let snappy_protocol_id = ProtocolId::new(protocol, version, Encoding::SSZSnappy);
let fork_context = Arc::new(fork_context()); let fork_context = Arc::new(fork_context());
let max_packet_size = max_rpc_size(&fork_context);
let mut snappy_outbound_codec = let mut snappy_outbound_codec =
SSZSnappyOutboundCodec::<Spec>::new(snappy_protocol_id, max_packet_size, fork_context); SSZSnappyOutboundCodec::<Spec>::new(snappy_protocol_id, max_packet_size, fork_context);
// decode message just as snappy message // decode message just as snappy message
@ -1124,7 +1124,7 @@ mod tests {
); );
} }
/// Test sending a message with encoded length prefix > MAX_RPC_SIZE. /// Test sending a message with encoded length prefix > max_rpc_size.
#[test] #[test]
fn test_decode_invalid_length() { fn test_decode_invalid_length() {
// 10 byte snappy stream identifier // 10 byte snappy stream identifier

View File

@ -5,7 +5,7 @@ use super::methods::{
GoodbyeReason, RPCCodedResponse, RPCResponseErrorCode, RequestId, ResponseTermination, GoodbyeReason, RPCCodedResponse, RPCResponseErrorCode, RequestId, ResponseTermination,
}; };
use super::outbound::OutboundRequestContainer; use super::outbound::OutboundRequestContainer;
use super::protocol::{InboundRequest, Protocol, RPCError, RPCProtocol}; use super::protocol::{max_rpc_size, InboundRequest, Protocol, RPCError, RPCProtocol};
use super::{RPCReceived, RPCSend}; use super::{RPCReceived, RPCSend};
use crate::rpc::outbound::{OutboundFramed, OutboundRequest}; use crate::rpc::outbound::{OutboundFramed, OutboundRequest};
use crate::rpc::protocol::InboundFramed; use crate::rpc::protocol::InboundFramed;
@ -951,6 +951,7 @@ where
OutboundRequestContainer { OutboundRequestContainer {
req: req.clone(), req: req.clone(),
fork_context: self.fork_context.clone(), fork_context: self.fork_context.clone(),
max_rpc_size: max_rpc_size(&self.fork_context),
}, },
(), (),
) )

View File

@ -30,7 +30,7 @@ pub use methods::{
RPCResponseErrorCode, RequestId, ResponseTermination, StatusMessage, MAX_REQUEST_BLOCKS, RPCResponseErrorCode, RequestId, ResponseTermination, StatusMessage, MAX_REQUEST_BLOCKS,
}; };
pub(crate) use outbound::OutboundRequest; pub(crate) use outbound::OutboundRequest;
pub use protocol::{Protocol, RPCError, MAX_RPC_SIZE}; pub use protocol::{max_rpc_size, Protocol, RPCError};
pub(crate) mod codec; pub(crate) mod codec;
mod handler; mod handler;
@ -186,6 +186,7 @@ where
SubstreamProtocol::new( SubstreamProtocol::new(
RPCProtocol { RPCProtocol {
fork_context: self.fork_context.clone(), fork_context: self.fork_context.clone(),
max_rpc_size: max_rpc_size(&self.fork_context),
phantom: PhantomData, phantom: PhantomData,
}, },
(), (),

View File

@ -2,7 +2,7 @@ use std::marker::PhantomData;
use super::methods::*; use super::methods::*;
use super::protocol::Protocol; use super::protocol::Protocol;
use super::protocol::{ProtocolId, MAX_RPC_SIZE}; use super::protocol::ProtocolId;
use super::RPCError; use super::RPCError;
use crate::rpc::protocol::Encoding; use crate::rpc::protocol::Encoding;
use crate::rpc::protocol::Version; use crate::rpc::protocol::Version;
@ -29,6 +29,7 @@ use types::{EthSpec, ForkContext};
pub struct OutboundRequestContainer<TSpec: EthSpec> { pub struct OutboundRequestContainer<TSpec: EthSpec> {
pub req: OutboundRequest<TSpec>, pub req: OutboundRequest<TSpec>,
pub fork_context: Arc<ForkContext>, pub fork_context: Arc<ForkContext>,
pub max_rpc_size: usize,
} }
#[derive(Debug, Clone, PartialEq)] #[derive(Debug, Clone, PartialEq)]
@ -150,7 +151,7 @@ where
Encoding::SSZSnappy => { Encoding::SSZSnappy => {
let ssz_snappy_codec = BaseOutboundCodec::new(SSZSnappyOutboundCodec::new( let ssz_snappy_codec = BaseOutboundCodec::new(SSZSnappyOutboundCodec::new(
protocol, protocol,
MAX_RPC_SIZE, self.max_rpc_size,
self.fork_context.clone(), self.fork_context.clone(),
)); ));
OutboundCodec::SSZSnappy(ssz_snappy_codec) OutboundCodec::SSZSnappy(ssz_snappy_codec)

View File

@ -22,7 +22,7 @@ use tokio_util::{
}; };
use types::{ use types::{
BeaconBlock, BeaconBlockAltair, BeaconBlockBase, BeaconBlockMerge, EthSpec, ForkContext, BeaconBlock, BeaconBlockAltair, BeaconBlockBase, BeaconBlockMerge, EthSpec, ForkContext,
Hash256, MainnetEthSpec, Signature, SignedBeaconBlock, ForkName, Hash256, MainnetEthSpec, Signature, SignedBeaconBlock,
}; };
lazy_static! { lazy_static! {
@ -92,8 +92,10 @@ lazy_static! {
} }
/// The maximum bytes that can be sent across the RPC. /// The maximum bytes that can be sent across the RPC pre-merge.
pub const MAX_RPC_SIZE: usize = 10 * 1_048_576; // 10M pub(crate) const MAX_RPC_SIZE: usize = 1_048_576; // 1M
/// The maximum bytes that can be sent across the RPC post-merge.
pub(crate) const MAX_RPC_SIZE_POST_MERGE: usize = 10 * 1_048_576; // 10M
/// The protocol prefix the RPC protocol id. /// The protocol prefix the RPC protocol id.
const PROTOCOL_PREFIX: &str = "/eth2/beacon_chain/req"; const PROTOCOL_PREFIX: &str = "/eth2/beacon_chain/req";
/// Time allowed for the first byte of a request to arrive before we time out (Time To First Byte). /// Time allowed for the first byte of a request to arrive before we time out (Time To First Byte).
@ -102,6 +104,15 @@ const TTFB_TIMEOUT: u64 = 5;
/// established before the stream is terminated. /// established before the stream is terminated.
const REQUEST_TIMEOUT: u64 = 15; const REQUEST_TIMEOUT: u64 = 15;
/// Returns the maximum bytes that can be sent across the RPC.
pub fn max_rpc_size(fork_context: &ForkContext) -> usize {
if fork_context.fork_exists(ForkName::Merge) {
MAX_RPC_SIZE_POST_MERGE
} else {
MAX_RPC_SIZE
}
}
/// Protocol names to be used. /// Protocol names to be used.
#[derive(Debug, Clone, Copy, PartialEq, Eq)] #[derive(Debug, Clone, Copy, PartialEq, Eq)]
pub enum Protocol { pub enum Protocol {
@ -170,6 +181,7 @@ impl std::fmt::Display for Version {
#[derive(Debug, Clone)] #[derive(Debug, Clone)]
pub struct RPCProtocol<TSpec: EthSpec> { pub struct RPCProtocol<TSpec: EthSpec> {
pub fork_context: Arc<ForkContext>, pub fork_context: Arc<ForkContext>,
pub max_rpc_size: usize,
pub phantom: PhantomData<TSpec>, pub phantom: PhantomData<TSpec>,
} }
@ -206,7 +218,7 @@ impl RpcLimits {
Self { min, max } Self { min, max }
} }
/// Returns true if the given length is greater than `MAX_RPC_SIZE` or out of /// Returns true if the given length is greater than `max_rpc_size` or out of
/// bounds for the given ssz type, returns false otherwise. /// bounds for the given ssz type, returns false otherwise.
pub fn is_out_of_bounds(&self, length: usize, max_rpc_size: usize) -> bool { pub fn is_out_of_bounds(&self, length: usize, max_rpc_size: usize) -> bool {
length > std::cmp::min(self.max, max_rpc_size) || length < self.min length > std::cmp::min(self.max, max_rpc_size) || length < self.min
@ -365,7 +377,7 @@ where
Encoding::SSZSnappy => { Encoding::SSZSnappy => {
let ssz_snappy_codec = BaseInboundCodec::new(SSZSnappyInboundCodec::new( let ssz_snappy_codec = BaseInboundCodec::new(SSZSnappyInboundCodec::new(
protocol, protocol,
MAX_RPC_SIZE, self.max_rpc_size,
self.fork_context.clone(), self.fork_context.clone(),
)); ));
InboundCodec::SSZSnappy(ssz_snappy_codec) InboundCodec::SSZSnappy(ssz_snappy_codec)

View File

@ -17,7 +17,7 @@ type E = MinimalEthSpec;
use tempfile::Builder as TempBuilder; use tempfile::Builder as TempBuilder;
/// Returns a dummy fork context /// Returns a dummy fork context
fn fork_context() -> ForkContext { pub fn fork_context() -> ForkContext {
let mut chain_spec = E::default_spec(); let mut chain_spec = E::default_spec();
// Set fork_epoch to `Some` to ensure that the `ForkContext` object // Set fork_epoch to `Some` to ensure that the `ForkContext` object
// includes altair in the list of forks // includes altair in the list of forks

View File

@ -1,7 +1,7 @@
#![cfg(test)] #![cfg(test)]
use lighthouse_network::rpc::methods::*; use lighthouse_network::rpc::methods::*;
use lighthouse_network::{ use lighthouse_network::{
rpc::MAX_RPC_SIZE, BehaviourEvent, Libp2pEvent, ReportSource, Request, Response, rpc::max_rpc_size, BehaviourEvent, Libp2pEvent, ReportSource, Request, Response,
}; };
use slog::{debug, warn, Level}; use slog::{debug, warn, Level};
use ssz::Encode; use ssz::Encode;
@ -11,16 +11,16 @@ use std::time::Duration;
use tokio::runtime::Runtime; use tokio::runtime::Runtime;
use tokio::time::sleep; use tokio::time::sleep;
use types::{ use types::{
BeaconBlock, BeaconBlockAltair, BeaconBlockBase, BeaconBlockMerge, Epoch, EthSpec, Hash256, BeaconBlock, BeaconBlockAltair, BeaconBlockBase, BeaconBlockMerge, Epoch, EthSpec, ForkContext,
MinimalEthSpec, Signature, SignedBeaconBlock, Slot, Hash256, MinimalEthSpec, Signature, SignedBeaconBlock, Slot,
}; };
mod common; mod common;
type E = MinimalEthSpec; type E = MinimalEthSpec;
/// Merge block with length < MAX_RPC_SIZE. /// Merge block with length < max_rpc_size.
fn merge_block_small() -> BeaconBlock<E> { fn merge_block_small(fork_context: &ForkContext) -> BeaconBlock<E> {
let mut block = BeaconBlockMerge::empty(&E::default_spec()); let mut block = BeaconBlockMerge::empty(&E::default_spec());
let tx = VariableList::from(vec![0; 1024]); let tx = VariableList::from(vec![0; 1024]);
let txs = VariableList::from(std::iter::repeat(tx).take(100).collect::<Vec<_>>()); let txs = VariableList::from(std::iter::repeat(tx).take(100).collect::<Vec<_>>());
@ -28,14 +28,14 @@ fn merge_block_small() -> BeaconBlock<E> {
block.body.execution_payload.transactions = txs; block.body.execution_payload.transactions = txs;
let block = BeaconBlock::Merge(block); let block = BeaconBlock::Merge(block);
assert!(block.ssz_bytes_len() <= MAX_RPC_SIZE); assert!(block.ssz_bytes_len() <= max_rpc_size(fork_context));
block block
} }
/// Merge block with length > MAX_RPC_SIZE. /// Merge block with length > MAX_RPC_SIZE.
/// The max limit for a merge block is in the order of ~16GiB which wouldn't fit in memory. /// The max limit for a merge block is in the order of ~16GiB which wouldn't fit in memory.
/// Hence, we generate a merge block just greater than `MAX_RPC_SIZE` to test rejection on the rpc layer. /// Hence, we generate a merge block just greater than `MAX_RPC_SIZE` to test rejection on the rpc layer.
fn merge_block_large() -> BeaconBlock<E> { fn merge_block_large(fork_context: &ForkContext) -> BeaconBlock<E> {
let mut block = BeaconBlockMerge::empty(&E::default_spec()); let mut block = BeaconBlockMerge::empty(&E::default_spec());
let tx = VariableList::from(vec![0; 1024]); let tx = VariableList::from(vec![0; 1024]);
let txs = VariableList::from(std::iter::repeat(tx).take(100000).collect::<Vec<_>>()); let txs = VariableList::from(std::iter::repeat(tx).take(100000).collect::<Vec<_>>());
@ -43,7 +43,7 @@ fn merge_block_large() -> BeaconBlock<E> {
block.body.execution_payload.transactions = txs; block.body.execution_payload.transactions = txs;
let block = BeaconBlock::Merge(block); let block = BeaconBlock::Merge(block);
assert!(block.ssz_bytes_len() > MAX_RPC_SIZE); assert!(block.ssz_bytes_len() > max_rpc_size(fork_context));
block block
} }
@ -180,7 +180,7 @@ fn test_blocks_by_range_chunked_rpc() {
let signed_full_block = SignedBeaconBlock::from_block(full_block, Signature::empty()); let signed_full_block = SignedBeaconBlock::from_block(full_block, Signature::empty());
let rpc_response_altair = Response::BlocksByRange(Some(Box::new(signed_full_block))); let rpc_response_altair = Response::BlocksByRange(Some(Box::new(signed_full_block)));
let full_block = merge_block_small(); let full_block = merge_block_small(&common::fork_context());
let signed_full_block = SignedBeaconBlock::from_block(full_block, Signature::empty()); let signed_full_block = SignedBeaconBlock::from_block(full_block, Signature::empty());
let rpc_response_merge_small = Response::BlocksByRange(Some(Box::new(signed_full_block))); let rpc_response_merge_small = Response::BlocksByRange(Some(Box::new(signed_full_block)));
@ -309,7 +309,7 @@ fn test_blocks_by_range_over_limit() {
}); });
// BlocksByRange Response // BlocksByRange Response
let full_block = merge_block_large(); let full_block = merge_block_large(&common::fork_context());
let signed_full_block = SignedBeaconBlock::from_block(full_block, Signature::empty()); let signed_full_block = SignedBeaconBlock::from_block(full_block, Signature::empty());
let rpc_response_merge_large = Response::BlocksByRange(Some(Box::new(signed_full_block))); let rpc_response_merge_large = Response::BlocksByRange(Some(Box::new(signed_full_block)));
@ -666,7 +666,7 @@ fn test_blocks_by_root_chunked_rpc() {
let signed_full_block = SignedBeaconBlock::from_block(full_block, Signature::empty()); let signed_full_block = SignedBeaconBlock::from_block(full_block, Signature::empty());
let rpc_response_altair = Response::BlocksByRoot(Some(Box::new(signed_full_block))); let rpc_response_altair = Response::BlocksByRoot(Some(Box::new(signed_full_block)));
let full_block = merge_block_small(); let full_block = merge_block_small(&common::fork_context());
let signed_full_block = SignedBeaconBlock::from_block(full_block, Signature::empty()); let signed_full_block = SignedBeaconBlock::from_block(full_block, Signature::empty());
let rpc_response_merge_small = Response::BlocksByRoot(Some(Box::new(signed_full_block))); let rpc_response_merge_small = Response::BlocksByRoot(Some(Box::new(signed_full_block)));

View File

@ -468,7 +468,8 @@ pub fn get_config<E: EthSpec>(
}; };
} }
client_config.chain.max_network_size = lighthouse_network::GOSSIP_MAX_SIZE; client_config.chain.max_network_size =
lighthouse_network::gossip_max_size(spec.merge_fork_epoch.is_some());
if cli_args.is_present("slasher") { if cli_args.is_present("slasher") {
let slasher_dir = if let Some(slasher_dir) = cli_args.value_of("slasher-dir") { let slasher_dir = if let Some(slasher_dir) = cli_args.value_of("slasher-dir") {

View File

@ -1,5 +1,4 @@
use crate::{test_utils::TestRandom, *}; use crate::{test_utils::TestRandom, *};
use safe_arith::{ArithError, SafeArith};
use serde_derive::{Deserialize, Serialize}; use serde_derive::{Deserialize, Serialize};
use ssz::Encode; use ssz::Encode;
use ssz_derive::{Decode, Encode}; use ssz_derive::{Decode, Encode};
@ -44,19 +43,6 @@ impl<T: EthSpec> ExecutionPayload<T> {
Self::default() Self::default()
} }
/// Returns the ssz size of `self`.
pub fn payload_size(&self) -> Result<usize, ArithError> {
let mut tx_size = ssz::BYTES_PER_LENGTH_OFFSET.safe_mul(self.transactions.len())?;
for tx in self.transactions.iter() {
tx_size.safe_add_assign(tx.len())?;
}
Self::empty()
.as_ssz_bytes()
.len()
.safe_add(<u8 as Encode>::ssz_fixed_len().safe_mul(self.extra_data.len())?)?
.safe_add(tx_size)
}
#[allow(clippy::integer_arithmetic)] #[allow(clippy::integer_arithmetic)]
/// Returns the maximum size of an execution payload. /// Returns the maximum size of an execution payload.
pub fn max_execution_payload_size() -> usize { pub fn max_execution_payload_size() -> usize {
@ -68,26 +54,3 @@ impl<T: EthSpec> ExecutionPayload<T> {
+ (T::max_transactions_per_payload() * (ssz::BYTES_PER_LENGTH_OFFSET + T::max_bytes_per_transaction())) + (T::max_transactions_per_payload() * (ssz::BYTES_PER_LENGTH_OFFSET + T::max_bytes_per_transaction()))
} }
} }
#[cfg(test)]
mod tests {
use super::*;
#[test]
fn test_payload_size() {
let mut payload = ExecutionPayload::<crate::MainnetEthSpec>::empty();
assert_eq!(
payload.as_ssz_bytes().len(),
payload.payload_size().unwrap()
);
payload.extra_data = VariableList::from(vec![42; 16]);
payload.transactions = VariableList::from(vec![VariableList::from(vec![42; 42])]);
assert_eq!(
payload.as_ssz_bytes().len(),
payload.payload_size().unwrap()
);
}
}

View File

@ -367,7 +367,7 @@ fn run<E: EthSpec>(
let logfile_compress = matches.is_present("logfile-compress"); let logfile_compress = matches.is_present("logfile-compress");
// Construct the path to the log file. // Construct the path to the log file.
let mut log_path: Option<PathBuf> = parse_optional(matches, "logfile")?; let mut log_path: Option<PathBuf> = clap_utils::parse_optional(matches, "logfile")?;
if log_path.is_none() { if log_path.is_none() {
log_path = match matches.subcommand_name() { log_path = match matches.subcommand_name() {
Some("beacon_node") => Some( Some("beacon_node") => Some(