// Copyright 2017-2020 Parity Technologies (UK) Ltd. // This file is part of Substrate. // Substrate is free software: you can redistribute it and/or modify // it under the terms of the GNU General Public License as published by // the Free Software Foundation, either version 3 of the License, or // (at your option) any later version. // Substrate is distributed in the hope that it will be useful, // but WITHOUT ANY WARRANTY; without even the implied warranty of // MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE. See the // GNU General Public License for more details. // You should have received a copy of the GNU General Public License // along with Substrate. If not, see . //! # System Module //! //! The System module provides low-level access to core types and cross-cutting utilities. //! It acts as the base layer for other pallets to interact with the Substrate framework components. //! //! - [`system::Trait`](./trait.Trait.html) //! //! ## Overview //! //! The System module defines the core data types used in a Substrate runtime. //! It also provides several utility functions (see [`Module`](./struct.Module.html)) for other FRAME pallets. //! //! In addition, it manages the storage items for extrinsics data, indexes, event records, and digest items, //! among other things that support the execution of the current block. //! //! It also handles low-level tasks like depositing logs, basic set up and take down of //! temporary storage entries, and access to previous block hashes. //! //! ## Interface //! //! ### Dispatchable Functions //! //! The System module does not implement any dispatchable functions. //! //! ### Public Functions //! //! See the [`Module`](./struct.Module.html) struct for details of publicly available functions. //! //! ### Signed Extensions //! //! The System module defines the following extensions: //! //! - [`CheckWeight`]: Checks the weight and length of the block and ensure that it does not //! exceed the limits. //! - [`CheckNonce`]: Checks the nonce of the transaction. Contains a single payload of type //! `T::Index`. //! - [`CheckEra`]: Checks the era of the transaction. Contains a single payload of type `Era`. //! - [`CheckGenesis`]: Checks the provided genesis hash of the transaction. Must be a part of the //! signed payload of the transaction. //! - [`CheckVersion`]: Checks that the runtime version is the same as the one encoded in the //! transaction. //! //! Lookup the runtime aggregator file (e.g. `node/runtime`) to see the full list of signed //! extensions included in a chain. //! //! ## Usage //! //! ### Prerequisites //! //! Import the System module and derive your module's configuration trait from the system trait. //! //! ### Example - Get extrinsic count and parent hash for the current block //! //! ``` //! use frame_support::{decl_module, dispatch}; //! use frame_system::{self as system, ensure_signed}; //! //! pub trait Trait: system::Trait {} //! //! decl_module! { //! pub struct Module for enum Call where origin: T::Origin { //! #[weight = 0] //! pub fn system_module_example(origin) -> dispatch::DispatchResult { //! let _sender = ensure_signed(origin)?; //! let _extrinsic_count = >::extrinsic_count(); //! let _parent_hash = >::parent_hash(); //! Ok(()) //! } //! } //! } //! # fn main() { } //! ``` #![cfg_attr(not(feature = "std"), no_std)] #[cfg(feature = "std")] use serde::Serialize; use sp_std::prelude::*; #[cfg(any(feature = "std", test))] use sp_std::map; use sp_std::convert::Infallible; use sp_std::marker::PhantomData; use sp_std::fmt::Debug; use sp_version::RuntimeVersion; use sp_runtime::{ RuntimeDebug, Perbill, DispatchOutcome, DispatchError, DispatchResult, generic::{self, Era}, transaction_validity::{ ValidTransaction, TransactionPriority, TransactionLongevity, TransactionValidityError, InvalidTransaction, TransactionValidity, }, traits::{ self, CheckEqual, AtLeast32Bit, Zero, SignedExtension, Lookup, LookupError, SimpleBitOps, Hash, Member, MaybeDisplay, BadOrigin, SaturatedConversion, MaybeSerialize, MaybeSerializeDeserialize, MaybeMallocSizeOf, StaticLookup, One, Bounded, Dispatchable, DispatchInfoOf, PostDispatchInfoOf, }, }; use sp_core::{ChangesTrieConfiguration, storage::well_known_keys}; use frame_support::{ decl_module, decl_event, decl_storage, decl_error, Parameter, ensure, debug, storage, traits::{ Contains, Get, ModuleToIndex, OnNewAccount, OnKilledAccount, IsDeadAccount, Happened, StoredMap, EnsureOrigin, }, weights::{ Weight, RuntimeDbWeight, DispatchInfo, PostDispatchInfo, DispatchClass, FunctionOf, Pays, } }; use codec::{Encode, Decode, FullCodec, EncodeLike}; #[cfg(any(feature = "std", test))] use sp_io::TestExternalities; pub mod offchain; /// Compute the trie root of a list of extrinsics. pub fn extrinsics_root(extrinsics: &[E]) -> H::Output { extrinsics_data_root::(extrinsics.iter().map(codec::Encode::encode).collect()) } /// Compute the trie root of a list of extrinsics. pub fn extrinsics_data_root(xts: Vec>) -> H::Output { H::ordered_trie_root(xts) } pub trait Trait: 'static + Eq + Clone { /// The aggregated `Origin` type used by dispatchable calls. type Origin: Into, Self::Origin>> + From> + Clone; /// The aggregated `Call` type. type Call: Dispatchable + Debug; /// Account index (aka nonce) type. This stores the number of previous transactions associated /// with a sender account. type Index: Parameter + Member + MaybeSerialize + Debug + Default + MaybeDisplay + AtLeast32Bit + Copy; /// The block number type used by the runtime. type BlockNumber: Parameter + Member + MaybeSerializeDeserialize + Debug + MaybeDisplay + AtLeast32Bit + Default + Bounded + Copy + sp_std::hash::Hash + sp_std::str::FromStr + MaybeMallocSizeOf; /// The output of the `Hashing` function. type Hash: Parameter + Member + MaybeSerializeDeserialize + Debug + MaybeDisplay + SimpleBitOps + Ord + Default + Copy + CheckEqual + sp_std::hash::Hash + AsRef<[u8]> + AsMut<[u8]> + MaybeMallocSizeOf; /// The hashing system (algorithm) being used in the runtime (e.g. Blake2). type Hashing: Hash; /// The user account identifier type for the runtime. type AccountId: Parameter + Member + MaybeSerializeDeserialize + Debug + MaybeDisplay + Ord + Default; /// Converting trait to take a source type and convert to `AccountId`. /// /// Used to define the type and conversion mechanism for referencing accounts in transactions. /// It's perfectly reasonable for this to be an identity conversion (with the source type being /// `AccountId`), but other modules (e.g. Indices module) may provide more functional/efficient /// alternatives. type Lookup: StaticLookup; /// The block header. type Header: Parameter + traits::Header< Number = Self::BlockNumber, Hash = Self::Hash, >; /// The aggregated event type of the runtime. type Event: Parameter + Member + From> + Debug; /// Maximum number of block number to block hash mappings to keep (oldest pruned first). type BlockHashCount: Get; /// The maximum weight of a block. type MaximumBlockWeight: Get; /// The weight of runtime database operations the runtime can invoke. type DbWeight: Get; /// The base weight of executing a block, independent of the transactions in the block. type BlockExecutionWeight: Get; /// The base weight of an Extrinsic in the block, independent of the of extrinsic being executed. type ExtrinsicBaseWeight: Get; /// The maximum length of a block (in bytes). type MaximumBlockLength: Get; /// The portion of the block that is available to normal transaction. The rest can only be used /// by operational transactions. This can be applied to any resource limit managed by the system /// module, including weight and length. type AvailableBlockRatio: Get; /// Get the chain's current version. type Version: Get; /// Convert a module to its index in the runtime. /// /// Expects the `ModuleToIndex` type that is being generated by `construct_runtime!` in the /// runtime. For tests it is okay to use `()` as type (returns `0` for each input). type ModuleToIndex: ModuleToIndex; /// Data to be associated with an account (other than nonce/transaction counter, which this /// module does regardless). type AccountData: Member + FullCodec + Clone + Default; /// Handler for when a new account has just been created. type OnNewAccount: OnNewAccount; /// A function that is invoked when an account has been determined to be dead. /// /// All resources should be cleaned up associated with the given account. type OnKilledAccount: OnKilledAccount; } pub type DigestOf = generic::Digest<::Hash>; pub type DigestItemOf = generic::DigestItem<::Hash>; pub type Key = Vec; pub type KeyValue = (Vec, Vec); /// A phase of a block's execution. #[derive(Encode, Decode, RuntimeDebug)] #[cfg_attr(feature = "std", derive(Serialize, PartialEq, Eq, Clone))] pub enum Phase { /// Applying an extrinsic. ApplyExtrinsic(u32), /// Finalizing the block. Finalization, /// Initializing the block. Initialization, } impl Default for Phase { fn default() -> Self { Self::Initialization } } /// Record of an event happening. #[derive(Encode, Decode, RuntimeDebug)] #[cfg_attr(feature = "std", derive(Serialize, PartialEq, Eq, Clone))] pub struct EventRecord { /// The phase of the block it happened in. pub phase: Phase, /// The event itself. pub event: E, /// The list of the topics this event has. pub topics: Vec, } /// Origin for the System module. #[derive(PartialEq, Eq, Clone, RuntimeDebug)] pub enum RawOrigin { /// The system itself ordained this dispatch to happen: this is the highest privilege level. Root, /// It is signed by some public key and we provide the `AccountId`. Signed(AccountId), /// It is signed by nobody, can be either: /// * included and agreed upon by the validators anyway, /// * or unsigned transaction validated by a module. None, } impl From> for RawOrigin { fn from(s: Option) -> RawOrigin { match s { Some(who) => RawOrigin::Signed(who), None => RawOrigin::None, } } } /// Exposed trait-generic origin type. pub type Origin = RawOrigin<::AccountId>; // Create a Hash with 69 for each byte, // only used to build genesis config. #[cfg(feature = "std")] fn hash69 + Default>() -> T { let mut h = T::default(); h.as_mut().iter_mut().for_each(|byte| *byte = 69); h } /// This type alias represents an index of an event. /// /// We use `u32` here because this index is used as index for `Events` /// which can't contain more than `u32::max_value()` items. type EventIndex = u32; /// Type used to encode the number of references an account has. pub type RefCount = u8; /// Information of an account. #[derive(Clone, Eq, PartialEq, Default, RuntimeDebug, Encode, Decode)] pub struct AccountInfo { /// The number of transactions this account has sent. pub nonce: Index, /// The number of other modules that currently depend on this account's existence. The account /// cannot be reaped until this is zero. pub refcount: RefCount, /// The additional data that belongs to this account. Used to store the balance(s) in a lot of /// chains. pub data: AccountData, } /// Stores the `spec_version` and `spec_name` of when the last runtime upgrade /// happened. #[derive(sp_runtime::RuntimeDebug, Encode, Decode)] #[cfg_attr(feature = "std", derive(PartialEq))] pub struct LastRuntimeUpgradeInfo { pub spec_version: codec::Compact, pub spec_name: sp_runtime::RuntimeString, } impl LastRuntimeUpgradeInfo { /// Returns if the runtime was upgraded in comparison of `self` and `current`. /// /// Checks if either the `spec_version` increased or the `spec_name` changed. pub fn was_upgraded(&self, current: &sp_version::RuntimeVersion) -> bool { current.spec_version > self.spec_version.0 || current.spec_name != self.spec_name } } impl From for LastRuntimeUpgradeInfo { fn from(version: sp_version::RuntimeVersion) -> Self { Self { spec_version: version.spec_version.into(), spec_name: version.spec_name, } } } decl_storage! { trait Store for Module as System { /// The full account information for a particular account ID. pub Account get(fn account): map hasher(blake2_128_concat) T::AccountId => AccountInfo; /// Total extrinsics count for the current block. ExtrinsicCount: Option; /// Total weight for all extrinsics put together, for the current block. AllExtrinsicsWeight: Option; /// Total length (in bytes) for all extrinsics put together, for the current block. AllExtrinsicsLen: Option; /// Map of block numbers to block hashes. pub BlockHash get(fn block_hash) build(|_| vec![(T::BlockNumber::zero(), hash69())]): map hasher(twox_64_concat) T::BlockNumber => T::Hash; /// Extrinsics data for the current block (maps an extrinsic's index to its data). ExtrinsicData get(fn extrinsic_data): map hasher(twox_64_concat) u32 => Vec; /// The current block number being processed. Set by `execute_block`. Number get(fn block_number): T::BlockNumber; /// Hash of the previous block. ParentHash get(fn parent_hash) build(|_| hash69()): T::Hash; /// Extrinsics root of the current block, also part of the block header. ExtrinsicsRoot get(fn extrinsics_root): T::Hash; /// Digest of the current block, also part of the block header. Digest get(fn digest): DigestOf; /// Events deposited for the current block. Events get(fn events): Vec>; /// The number of events in the `Events` list. EventCount get(fn event_count): EventIndex; // TODO: https://github.com/paritytech/substrate/issues/2553 // Possibly, we can improve it by using something like: // `Option<(BlockNumber, Vec)>`, however in this case we won't be able to use // `EventTopics::append`. /// Mapping between a topic (represented by T::Hash) and a vector of indexes /// of events in the `>` list. /// /// All topic vectors have deterministic storage locations depending on the topic. This /// allows light-clients to leverage the changes trie storage tracking mechanism and /// in case of changes fetch the list of events of interest. /// /// The value has the type `(T::BlockNumber, EventIndex)` because if we used only just /// the `EventIndex` then in case if the topic has the same contents on the next block /// no notification will be triggered thus the event might be lost. EventTopics get(fn event_topics): map hasher(blake2_128_concat) T::Hash => Vec<(T::BlockNumber, EventIndex)>; /// Stores the `spec_version` and `spec_name` of when the last runtime upgrade happened. pub LastRuntimeUpgrade build(|_| Some(LastRuntimeUpgradeInfo::from(T::Version::get()))): Option; /// The execution phase of the block. ExecutionPhase: Option; } add_extra_genesis { config(changes_trie_config): Option; #[serde(with = "sp_core::bytes")] config(code): Vec; build(|config: &GenesisConfig| { use codec::Encode; sp_io::storage::set(well_known_keys::CODE, &config.code); sp_io::storage::set(well_known_keys::EXTRINSIC_INDEX, &0u32.encode()); if let Some(ref changes_trie_config) = config.changes_trie_config { sp_io::storage::set( well_known_keys::CHANGES_TRIE_CONFIG, &changes_trie_config.encode(), ); } }); } } decl_event!( /// Event for the System module. pub enum Event where AccountId = ::AccountId { /// An extrinsic completed successfully. ExtrinsicSuccess(DispatchInfo), /// An extrinsic failed. ExtrinsicFailed(DispatchError, DispatchInfo), /// `:code` was updated. CodeUpdated, /// A new account was created. NewAccount(AccountId), /// An account was reaped. KilledAccount(AccountId), } ); decl_error! { /// Error for the System module pub enum Error for Module { /// The name of specification does not match between the current runtime /// and the new runtime. InvalidSpecName, /// The specification version is not allowed to decrease between the current runtime /// and the new runtime. SpecVersionNeedsToIncrease, /// Failed to extract the runtime version from the new runtime. /// /// Either calling `Core_version` or decoding `RuntimeVersion` failed. FailedToExtractRuntimeVersion, /// Suicide called when the account has non-default composite data. NonDefaultComposite, /// There is a non-zero reference count preventing the account from being purged. NonZeroRefCount, } } decl_module! { pub struct Module for enum Call where origin: T::Origin { type Error = Error; /// The maximum weight of a block. const MaximumBlockWeight: Weight = T::MaximumBlockWeight::get(); /// The weight of runtime database operations the runtime can invoke. const DbWeight: RuntimeDbWeight = T::DbWeight::get(); /// The base weight of executing a block, independent of the transactions in the block. const BlockExecutionWeight: Weight = T::BlockExecutionWeight::get(); /// The base weight of an Extrinsic in the block, independent of the of extrinsic being executed. const ExtrinsicBaseWeight: Weight = T::ExtrinsicBaseWeight::get(); /// The maximum length of a block (in bytes). const MaximumBlockLength: u32 = T::MaximumBlockLength::get(); /// A dispatch that will fill the block weight up to the given ratio. // TODO: This should only be available for testing, rather than in general usage, but // that's not possible at present (since it's within the decl_module macro). #[weight = FunctionOf( |(ratio,): (&Perbill,)| *ratio * T::MaximumBlockWeight::get(), DispatchClass::Operational, Pays::Yes, )] fn fill_block(origin, _ratio: Perbill) { ensure_root(origin)?; } /// Make some on-chain remark. /// /// # /// - `O(1)` /// # #[weight = 0] fn remark(origin, _remark: Vec) { ensure_signed(origin)?; } /// Set the number of pages in the WebAssembly environment's heap. /// /// # /// - `O(1)` /// - 1 storage write. /// # #[weight = (0, DispatchClass::Operational)] fn set_heap_pages(origin, pages: u64) { ensure_root(origin)?; storage::unhashed::put_raw(well_known_keys::HEAP_PAGES, &pages.encode()); } /// Set the new runtime code. /// /// # /// - `O(C + S)` where `C` length of `code` and `S` complexity of `can_set_code` /// - 1 storage write (codec `O(C)`). /// - 1 call to `can_set_code`: `O(S)` (calls `sp_io::misc::runtime_version` which is expensive). /// - 1 event. /// # #[weight = (200_000_000, DispatchClass::Operational)] pub fn set_code(origin, code: Vec) { Self::can_set_code(origin, &code)?; storage::unhashed::put_raw(well_known_keys::CODE, &code); Self::deposit_event(RawEvent::CodeUpdated); } /// Set the new runtime code without doing any checks of the given `code`. /// /// # /// - `O(C)` where `C` length of `code` /// - 1 storage write (codec `O(C)`). /// - 1 event. /// # #[weight = (200_000_000, DispatchClass::Operational)] pub fn set_code_without_checks(origin, code: Vec) { ensure_root(origin)?; storage::unhashed::put_raw(well_known_keys::CODE, &code); Self::deposit_event(RawEvent::CodeUpdated); } /// Set the new changes trie configuration. /// /// # /// - `O(D)` where `D` length of `Digest` /// - 1 storage write or delete (codec `O(1)`). /// - 1 call to `deposit_log`: `O(D)` (which depends on the length of `Digest`) /// # #[weight = (20_000_000, DispatchClass::Operational)] pub fn set_changes_trie_config(origin, changes_trie_config: Option) { ensure_root(origin)?; match changes_trie_config.clone() { Some(changes_trie_config) => storage::unhashed::put_raw( well_known_keys::CHANGES_TRIE_CONFIG, &changes_trie_config.encode(), ), None => storage::unhashed::kill(well_known_keys::CHANGES_TRIE_CONFIG), } let log = generic::DigestItem::ChangesTrieSignal( generic::ChangesTrieSignal::NewConfiguration(changes_trie_config), ); Self::deposit_log(log.into()); } /// Set some items of storage. /// /// # /// - `O(I)` where `I` length of `items` /// - `I` storage writes (`O(1)`). /// # #[weight = (0, DispatchClass::Operational)] fn set_storage(origin, items: Vec) { ensure_root(origin)?; for i in &items { storage::unhashed::put_raw(&i.0, &i.1); } } /// Kill some items from storage. /// /// # /// - `O(VK)` where `V` length of `keys` and `K` length of one key /// - `V` storage deletions. /// # #[weight = (0, DispatchClass::Operational)] fn kill_storage(origin, keys: Vec) { ensure_root(origin)?; for key in &keys { storage::unhashed::kill(&key); } } /// Kill all storage items with a key that starts with the given prefix. /// /// # /// - `O(P)` where `P` amount of keys with prefix `prefix` /// - `P` storage deletions. /// # #[weight = (0, DispatchClass::Operational)] fn kill_prefix(origin, prefix: Key) { ensure_root(origin)?; storage::unhashed::kill_prefix(&prefix); } /// Kill the sending account, assuming there are no references outstanding and the composite /// data is equal to its default value. /// /// # /// - `O(1)` /// - 1 storage read and deletion. /// # #[weight = (25_000_000, DispatchClass::Operational)] fn suicide(origin) { let who = ensure_signed(origin)?; let account = Account::::get(&who); ensure!(account.refcount == 0, Error::::NonZeroRefCount); ensure!(account.data == T::AccountData::default(), Error::::NonDefaultComposite); Account::::remove(who); } } } pub struct EnsureRoot(sp_std::marker::PhantomData); impl< O: Into, O>> + From>, AccountId, > EnsureOrigin for EnsureRoot { type Success = (); fn try_origin(o: O) -> Result { o.into().and_then(|o| match o { RawOrigin::Root => Ok(()), r => Err(O::from(r)), }) } #[cfg(feature = "runtime-benchmarks")] fn successful_origin() -> O { O::from(RawOrigin::Root) } } pub struct EnsureSigned(sp_std::marker::PhantomData); impl< O: Into, O>> + From>, AccountId: Default, > EnsureOrigin for EnsureSigned { type Success = AccountId; fn try_origin(o: O) -> Result { o.into().and_then(|o| match o { RawOrigin::Signed(who) => Ok(who), r => Err(O::from(r)), }) } #[cfg(feature = "runtime-benchmarks")] fn successful_origin() -> O { O::from(RawOrigin::Signed(Default::default())) } } pub struct EnsureSignedBy(sp_std::marker::PhantomData<(Who, AccountId)>); impl< O: Into, O>> + From>, Who: Contains, AccountId: PartialEq + Clone + Ord + Default, > EnsureOrigin for EnsureSignedBy { type Success = AccountId; fn try_origin(o: O) -> Result { o.into().and_then(|o| match o { RawOrigin::Signed(ref who) if Who::contains(who) => Ok(who.clone()), r => Err(O::from(r)), }) } #[cfg(feature = "runtime-benchmarks")] fn successful_origin() -> O { let members = Who::sorted_members(); let first_member = match members.get(0) { Some(account) => account.clone(), None => Default::default(), }; O::from(RawOrigin::Signed(first_member.clone())) } } pub struct EnsureNone(sp_std::marker::PhantomData); impl< O: Into, O>> + From>, AccountId, > EnsureOrigin for EnsureNone { type Success = (); fn try_origin(o: O) -> Result { o.into().and_then(|o| match o { RawOrigin::None => Ok(()), r => Err(O::from(r)), }) } #[cfg(feature = "runtime-benchmarks")] fn successful_origin() -> O { O::from(RawOrigin::None) } } pub struct EnsureNever(sp_std::marker::PhantomData); impl EnsureOrigin for EnsureNever { type Success = T; fn try_origin(o: O) -> Result { Err(o) } #[cfg(feature = "runtime-benchmarks")] fn successful_origin() -> O { unimplemented!() } } /// Ensure that the origin `o` represents a signed extrinsic (i.e. transaction). /// Returns `Ok` with the account that signed the extrinsic or an `Err` otherwise. pub fn ensure_signed(o: OuterOrigin) -> Result where OuterOrigin: Into, OuterOrigin>> { match o.into() { Ok(RawOrigin::Signed(t)) => Ok(t), _ => Err(BadOrigin), } } /// Ensure that the origin `o` represents the root. Returns `Ok` or an `Err` otherwise. pub fn ensure_root(o: OuterOrigin) -> Result<(), BadOrigin> where OuterOrigin: Into, OuterOrigin>> { match o.into() { Ok(RawOrigin::Root) => Ok(()), _ => Err(BadOrigin), } } /// Ensure that the origin `o` represents an unsigned extrinsic. Returns `Ok` or an `Err` otherwise. pub fn ensure_none(o: OuterOrigin) -> Result<(), BadOrigin> where OuterOrigin: Into, OuterOrigin>> { match o.into() { Ok(RawOrigin::None) => Ok(()), _ => Err(BadOrigin), } } /// A type of block initialization to perform. pub enum InitKind { /// Leave inspectable storage entries in state. /// /// i.e. `Events` are not being reset. /// Should only be used for off-chain calls, /// regular block execution should clear those. Inspection, /// Reset also inspectable storage entries. /// /// This should be used for regular block execution. Full, } impl Default for InitKind { fn default() -> Self { InitKind::Full } } /// Reference status; can be either referenced or unreferenced. pub enum RefStatus { Referenced, Unreferenced, } impl Module { /// Deposits an event into this block's event record. pub fn deposit_event(event: impl Into) { Self::deposit_event_indexed(&[], event.into()); } /// Increment the reference counter on an account. pub fn inc_ref(who: &T::AccountId) { Account::::mutate(who, |a| a.refcount = a.refcount.saturating_add(1)); } /// Decrement the reference counter on an account. This *MUST* only be done once for every time /// you called `inc_ref` on `who`. pub fn dec_ref(who: &T::AccountId) { Account::::mutate(who, |a| a.refcount = a.refcount.saturating_sub(1)); } /// The number of outstanding references for the account `who`. pub fn refs(who: &T::AccountId) -> RefCount { Account::::get(who).refcount } /// True if the account has no outstanding references. pub fn allow_death(who: &T::AccountId) -> bool { Account::::get(who).refcount == 0 } /// Deposits an event into this block's event record adding this event /// to the corresponding topic indexes. /// /// This will update storage entries that correspond to the specified topics. /// It is expected that light-clients could subscribe to this topics. pub fn deposit_event_indexed(topics: &[T::Hash], event: T::Event) { let block_number = Self::block_number(); // Don't populate events on genesis. if block_number.is_zero() { return } let phase = ExecutionPhase::get().unwrap_or_default(); let event = EventRecord { phase, event, topics: topics.iter().cloned().collect::>(), }; // Index of the to be added event. let event_idx = { let old_event_count = EventCount::get(); let new_event_count = match old_event_count.checked_add(1) { // We've reached the maximum number of events at this block, just // don't do anything and leave the event_count unaltered. None => return, Some(nc) => nc, }; EventCount::put(new_event_count); old_event_count }; Events::::append(&event); for topic in topics { >::append(topic, &(block_number, event_idx)); } } /// Gets the index of extrinsic that is currently executing. pub fn extrinsic_index() -> Option { storage::unhashed::get(well_known_keys::EXTRINSIC_INDEX) } /// Gets extrinsics count. pub fn extrinsic_count() -> u32 { ExtrinsicCount::get().unwrap_or_default() } /// Gets a total weight of all executed extrinsics. pub fn all_extrinsics_weight() -> Weight { AllExtrinsicsWeight::get().unwrap_or_default() } /// Get the quota ratio of each dispatch class type. This indicates that all operational and mandatory /// dispatches can use the full capacity of any resource, while user-triggered ones can consume /// a portion. pub fn get_dispatch_limit_ratio(class: DispatchClass) -> Perbill { match class { DispatchClass::Operational | DispatchClass::Mandatory => ::one(), DispatchClass::Normal => T::AvailableBlockRatio::get(), } } /// The maximum weight of an allowable extrinsic. Only one of these could exist in a block. pub fn max_extrinsic_weight(class: DispatchClass) -> Weight { let limit = Self::get_dispatch_limit_ratio(class) * T::MaximumBlockWeight::get(); limit - (T::BlockExecutionWeight::get() + T::ExtrinsicBaseWeight::get()) } pub fn all_extrinsics_len() -> u32 { AllExtrinsicsLen::get().unwrap_or_default() } /// Inform the system module of some additional weight that should be accounted for, in the /// current block. /// /// NOTE: use with extra care; this function is made public only be used for certain modules /// that need it. A runtime that does not have dynamic calls should never need this and should /// stick to static weights. A typical use case for this is inner calls or smart contract calls. /// Furthermore, it only makes sense to use this when it is presumably _cheap_ to provide the /// argument `weight`; In other words, if this function is to be used to account for some /// unknown, user provided call's weight, it would only make sense to use it if you are sure you /// can rapidly compute the weight of the inner call. /// /// Even more dangerous is to note that this function does NOT take any action, if the new sum /// of block weight is more than the block weight limit. This is what the _unchecked_. /// /// Another potential use-case could be for the `on_initialize` and `on_finalize` hooks. /// /// If no previous weight exists, the function initializes the weight to zero. pub fn register_extra_weight_unchecked(weight: Weight) { let current_weight = AllExtrinsicsWeight::get().unwrap_or_default(); let next_weight = current_weight.saturating_add(weight); AllExtrinsicsWeight::put(next_weight); } /// Start the execution of a particular block. pub fn initialize( number: &T::BlockNumber, parent_hash: &T::Hash, txs_root: &T::Hash, digest: &DigestOf, kind: InitKind, ) { // populate environment ExecutionPhase::put(Phase::Initialization); storage::unhashed::put(well_known_keys::EXTRINSIC_INDEX, &0u32); >::put(number); >::put(digest); >::put(parent_hash); >::insert(*number - One::one(), parent_hash); >::put(txs_root); if let InitKind::Full = kind { >::kill(); EventCount::kill(); >::remove_all(); } } /// Remove temporary "environment" entries in storage. pub fn finalize() -> T::Header { ExecutionPhase::kill(); ExtrinsicCount::kill(); AllExtrinsicsWeight::kill(); AllExtrinsicsLen::kill(); let number = >::take(); let parent_hash = >::take(); let mut digest = >::take(); let extrinsics_root = >::take(); // move block hash pruning window by one block let block_hash_count = ::get(); if number > block_hash_count { let to_remove = number - block_hash_count - One::one(); // keep genesis hash if to_remove != Zero::zero() { >::remove(to_remove); } } let storage_root = T::Hash::decode(&mut &sp_io::storage::root()[..]) .expect("Node is configured to use the same hash; qed"); let storage_changes_root = sp_io::storage::changes_root(&parent_hash.encode()); // we can't compute changes trie root earlier && put it to the Digest // because it will include all currently existing temporaries. if let Some(storage_changes_root) = storage_changes_root { let item = generic::DigestItem::ChangesTrieRoot( T::Hash::decode(&mut &storage_changes_root[..]) .expect("Node is configured to use the same hash; qed") ); digest.push(item); } // The following fields // // - > // - > // - > // // stay to be inspected by the client and will be cleared by `Self::initialize`. ::new(number, extrinsics_root, storage_root, parent_hash, digest) } /// Deposits a log and ensures it matches the block's log data. /// /// # /// - `O(1)` /// - 1 storage write (codec `O(1)`) /// # pub fn deposit_log(item: DigestItemOf) { >::append(item); } /// Get the basic externalities for this module, useful for tests. #[cfg(any(feature = "std", test))] pub fn externalities() -> TestExternalities { TestExternalities::new(sp_core::storage::Storage { top: map![ >::hashed_key_for(T::BlockNumber::zero()) => [69u8; 32].encode(), >::hashed_key().to_vec() => T::BlockNumber::one().encode(), >::hashed_key().to_vec() => [69u8; 32].encode() ], children_default: map![], }) } /// Set the block number to something in particular. Can be used as an alternative to /// `initialize` for tests that don't need to bother with the other environment entries. #[cfg(any(feature = "std", feature = "runtime-benchmarks", test))] pub fn set_block_number(n: T::BlockNumber) { >::put(n); } /// Sets the index of extrinsic that is currently executing. #[cfg(any(feature = "std", test))] pub fn set_extrinsic_index(extrinsic_index: u32) { storage::unhashed::put(well_known_keys::EXTRINSIC_INDEX, &extrinsic_index) } /// Set the parent hash number to something in particular. Can be used as an alternative to /// `initialize` for tests that don't need to bother with the other environment entries. #[cfg(any(feature = "std", test))] pub fn set_parent_hash(n: T::Hash) { >::put(n); } /// Set the current block weight. This should only be used in some integration tests. #[cfg(any(feature = "std", test))] pub fn set_block_limits(weight: Weight, len: usize) { AllExtrinsicsWeight::put(weight); AllExtrinsicsLen::put(len as u32); } /// Return the chain's current runtime version. pub fn runtime_version() -> RuntimeVersion { T::Version::get() } /// Retrieve the account transaction counter from storage. pub fn account_nonce(who: impl EncodeLike) -> T::Index { Account::::get(who).nonce } /// Increment a particular account's nonce by 1. pub fn inc_account_nonce(who: impl EncodeLike) { Account::::mutate(who, |a| a.nonce += T::Index::one()); } /// Note what the extrinsic data of the current extrinsic index is. If this /// is called, then ensure `derive_extrinsics` is also called before /// block-building is completed. /// /// NOTE: This function is called only when the block is being constructed locally. /// `execute_block` doesn't note any extrinsics. pub fn note_extrinsic(encoded_xt: Vec) { ExtrinsicData::insert(Self::extrinsic_index().unwrap_or_default(), encoded_xt); } /// To be called immediately after an extrinsic has been applied. pub fn note_applied_extrinsic(r: &DispatchOutcome, _encoded_len: u32, info: DispatchInfo) { Self::deposit_event( match r { Ok(()) => RawEvent::ExtrinsicSuccess(info), Err(err) => { sp_runtime::print(err); RawEvent::ExtrinsicFailed(err.clone(), info) }, } ); let next_extrinsic_index = Self::extrinsic_index().unwrap_or_default() + 1u32; storage::unhashed::put(well_known_keys::EXTRINSIC_INDEX, &next_extrinsic_index); ExecutionPhase::put(Phase::ApplyExtrinsic(next_extrinsic_index)); } /// To be called immediately after `note_applied_extrinsic` of the last extrinsic of the block /// has been called. pub fn note_finished_extrinsics() { let extrinsic_index: u32 = storage::unhashed::take(well_known_keys::EXTRINSIC_INDEX) .unwrap_or_default(); ExtrinsicCount::put(extrinsic_index); ExecutionPhase::put(Phase::Finalization); } /// To be called immediately after finishing the initialization of the block /// (e.g., called `on_initialize` for all modules). pub fn note_finished_initialize() { ExecutionPhase::put(Phase::ApplyExtrinsic(0)) } /// Remove all extrinsic data and save the extrinsics trie root. pub fn derive_extrinsics() { let extrinsics = (0..ExtrinsicCount::get().unwrap_or_default()) .map(ExtrinsicData::take).collect(); let xts_root = extrinsics_data_root::(extrinsics); >::put(xts_root); } /// An account is being created. pub fn on_created_account(who: T::AccountId) { T::OnNewAccount::on_new_account(&who); Self::deposit_event(RawEvent::NewAccount(who)); } /// Do anything that needs to be done after an account has been killed. fn on_killed_account(who: T::AccountId) { T::OnKilledAccount::on_killed_account(&who); Self::deposit_event(RawEvent::KilledAccount(who)); } /// Remove an account from storage. This should only be done when its refs are zero or you'll /// get storage leaks in other modules. Nonetheless we assume that the calling logic knows best. /// /// This is a no-op if the account doesn't already exist. If it does then it will ensure /// cleanups (those in `on_killed_account`) take place. fn kill_account(who: &T::AccountId) { if Account::::contains_key(who) { let account = Account::::take(who); if account.refcount > 0 { debug::debug!( target: "system", "WARNING: Referenced account deleted. This is probably a bug." ); } Module::::on_killed_account(who.clone()); } } /// Determine whether or not it is possible to update the code. /// /// This function has no side effects and is idempotent, but is fairly /// heavy. It is automatically called by `set_code`; in most cases, /// a direct call to `set_code` is preferable. It is useful to call /// `can_set_code` when it is desirable to perform the appropriate /// runtime checks without actually changing the code yet. pub fn can_set_code(origin: T::Origin, code: &[u8]) -> Result<(), sp_runtime::DispatchError> { ensure_root(origin)?; let current_version = T::Version::get(); let new_version = sp_io::misc::runtime_version(&code) .and_then(|v| RuntimeVersion::decode(&mut &v[..]).ok()) .ok_or_else(|| Error::::FailedToExtractRuntimeVersion)?; if new_version.spec_name != current_version.spec_name { Err(Error::::InvalidSpecName)? } if new_version.spec_version <= current_version.spec_version { Err(Error::::SpecVersionNeedsToIncrease)? } Ok(()) } } /// Event handler which calls on_created_account when it happens. pub struct CallOnCreatedAccount(PhantomData); impl Happened for CallOnCreatedAccount { fn happened(who: &T::AccountId) { Module::::on_created_account(who.clone()); } } /// Event handler which calls kill_account when it happens. pub struct CallKillAccount(PhantomData); impl Happened for CallKillAccount { fn happened(who: &T::AccountId) { Module::::kill_account(who) } } // Implement StoredMap for a simple single-item, kill-account-on-remove system. This works fine for // storing a single item which is required to not be empty/default for the account to exist. // Anything more complex will need more sophisticated logic. impl StoredMap for Module { fn get(k: &T::AccountId) -> T::AccountData { Account::::get(k).data } fn is_explicit(k: &T::AccountId) -> bool { Account::::contains_key(k) } fn insert(k: &T::AccountId, data: T::AccountData) { let existed = Account::::contains_key(k); Account::::mutate(k, |a| a.data = data); if !existed { Self::on_created_account(k.clone()); } } fn remove(k: &T::AccountId) { Self::kill_account(k) } fn mutate(k: &T::AccountId, f: impl FnOnce(&mut T::AccountData) -> R) -> R { let existed = Account::::contains_key(k); let r = Account::::mutate(k, |a| f(&mut a.data)); if !existed { Self::on_created_account(k.clone()); } r } fn mutate_exists(k: &T::AccountId, f: impl FnOnce(&mut Option) -> R) -> R { Self::try_mutate_exists(k, |x| -> Result { Ok(f(x)) }).expect("Infallible; qed") } fn try_mutate_exists(k: &T::AccountId, f: impl FnOnce(&mut Option) -> Result) -> Result { Account::::try_mutate_exists(k, |maybe_value| { let existed = maybe_value.is_some(); let (maybe_prefix, mut maybe_data) = split_inner( maybe_value.take(), |account| ((account.nonce, account.refcount), account.data) ); f(&mut maybe_data).map(|result| { *maybe_value = maybe_data.map(|data| { let (nonce, refcount) = maybe_prefix.unwrap_or_default(); AccountInfo { nonce, refcount, data } }); (existed, maybe_value.is_some(), result) }) }).map(|(existed, exists, v)| { if !existed && exists { Self::on_created_account(k.clone()); } else if existed && !exists { Self::on_killed_account(k.clone()); } v }) } } /// Split an `option` into two constituent options, as defined by a `splitter` function. pub fn split_inner(option: Option, splitter: impl FnOnce(T) -> (R, S)) -> (Option, Option) { match option { Some(inner) => { let (r, s) = splitter(inner); (Some(r), Some(s)) } None => (None, None), } } /// resource limit check. #[derive(Encode, Decode, Clone, Eq, PartialEq)] pub struct CheckWeight(PhantomData); impl CheckWeight where T::Call: Dispatchable { /// Get the quota ratio of each dispatch class type. This indicates that all operational and mandatory /// dispatches can use the full capacity of any resource, while user-triggered ones can consume /// a portion. fn get_dispatch_limit_ratio(class: DispatchClass) -> Perbill { Module::::get_dispatch_limit_ratio(class) } /// Checks if the current extrinsic can fit into the block with respect to block weight limits. /// /// Upon successes, it returns the new block weight as a `Result`. fn check_weight( info: &DispatchInfoOf, ) -> Result { let current_weight = Module::::all_extrinsics_weight(); let maximum_weight = T::MaximumBlockWeight::get(); let limit = Self::get_dispatch_limit_ratio(info.class) * maximum_weight; if info.class == DispatchClass::Mandatory { // If we have a dispatch that must be included in the block, it ignores all the limits. let extrinsic_weight = info.weight.saturating_add(T::ExtrinsicBaseWeight::get()); let next_weight = current_weight.saturating_add(extrinsic_weight); Ok(next_weight) } else { let extrinsic_weight = info.weight.checked_add(T::ExtrinsicBaseWeight::get()) .ok_or(InvalidTransaction::ExhaustsResources)?; let next_weight = current_weight.checked_add(extrinsic_weight) .ok_or(InvalidTransaction::ExhaustsResources)?; if next_weight > limit { Err(InvalidTransaction::ExhaustsResources.into()) } else { Ok(next_weight) } } } /// Checks if the current extrinsic can fit into the block with respect to block length limits. /// /// Upon successes, it returns the new block length as a `Result`. fn check_block_length( info: &DispatchInfoOf, len: usize, ) -> Result { let current_len = Module::::all_extrinsics_len(); let maximum_len = T::MaximumBlockLength::get(); let limit = Self::get_dispatch_limit_ratio(info.class) * maximum_len; let added_len = len as u32; let next_len = current_len.saturating_add(added_len); if next_len > limit { Err(InvalidTransaction::ExhaustsResources.into()) } else { Ok(next_len) } } /// get the priority of an extrinsic denoted by `info`. fn get_priority(info: &DispatchInfoOf) -> TransactionPriority { match info.class { DispatchClass::Normal => info.weight.into(), DispatchClass::Operational => Bounded::max_value(), // Mandatory extrinsics are only for inherents; never transactions. DispatchClass::Mandatory => Bounded::min_value(), } } /// Creates new `SignedExtension` to check weight of the extrinsic. pub fn new() -> Self { Self(PhantomData) } /// Do the pre-dispatch checks. This can be applied to both signed and unsigned. /// /// It checks and notes the new weight and length. fn do_pre_dispatch( info: &DispatchInfoOf, len: usize, ) -> Result<(), TransactionValidityError> { let next_len = Self::check_block_length(info, len)?; let next_weight = Self::check_weight(info)?; AllExtrinsicsLen::put(next_len); AllExtrinsicsWeight::put(next_weight); Ok(()) } /// Do the validate checks. This can be applied to both signed and unsigned. /// /// It only checks that the block weight and length limit will not exceed. fn do_validate( info: &DispatchInfoOf, len: usize, ) -> TransactionValidity { // ignore the next weight and length. If they return `Ok`, then it is below the limit. let _ = Self::check_block_length(info, len)?; let _ = Self::check_weight(info)?; Ok(ValidTransaction { priority: Self::get_priority(info), ..Default::default() }) } } impl SignedExtension for CheckWeight where T::Call: Dispatchable { type AccountId = T::AccountId; type Call = T::Call; type AdditionalSigned = (); type Pre = (); const IDENTIFIER: &'static str = "CheckWeight"; fn additional_signed(&self) -> sp_std::result::Result<(), TransactionValidityError> { Ok(()) } fn pre_dispatch( self, _who: &Self::AccountId, _call: &Self::Call, info: &DispatchInfoOf, len: usize, ) -> Result<(), TransactionValidityError> { if info.class == DispatchClass::Mandatory { Err(InvalidTransaction::MandatoryDispatch)? } Self::do_pre_dispatch(info, len) } fn validate( &self, _who: &Self::AccountId, _call: &Self::Call, info: &DispatchInfoOf, len: usize, ) -> TransactionValidity { if info.class == DispatchClass::Mandatory { Err(InvalidTransaction::MandatoryDispatch)? } Self::do_validate(info, len) } fn pre_dispatch_unsigned( _call: &Self::Call, info: &DispatchInfoOf, len: usize, ) -> Result<(), TransactionValidityError> { Self::do_pre_dispatch(info, len) } fn validate_unsigned( _call: &Self::Call, info: &DispatchInfoOf, len: usize, ) -> TransactionValidity { Self::do_validate(info, len) } fn post_dispatch( _pre: Self::Pre, info: &DispatchInfoOf, post_info: &PostDispatchInfoOf, _len: usize, result: &DispatchResult, ) -> Result<(), TransactionValidityError> { // Since mandatory dispatched do not get validated for being overweight, we are sensitive // to them actually being useful. Block producers are thus not allowed to include mandatory // extrinsics that result in error. if info.class == DispatchClass::Mandatory && result.is_err() { Err(InvalidTransaction::BadMandatory)? } let unspent = post_info.calc_unspent(info); if unspent > 0 { AllExtrinsicsWeight::mutate(|weight| { *weight = weight.map(|w| w.saturating_sub(unspent)); }) } Ok(()) } } impl Debug for CheckWeight { #[cfg(feature = "std")] fn fmt(&self, f: &mut sp_std::fmt::Formatter) -> sp_std::fmt::Result { write!(f, "CheckWeight") } #[cfg(not(feature = "std"))] fn fmt(&self, _: &mut sp_std::fmt::Formatter) -> sp_std::fmt::Result { Ok(()) } } /// Nonce check and increment to give replay protection for transactions. #[derive(Encode, Decode, Clone, Eq, PartialEq)] pub struct CheckNonce(#[codec(compact)] T::Index); impl CheckNonce { /// utility constructor. Used only in client/factory code. pub fn from(nonce: T::Index) -> Self { Self(nonce) } } impl Debug for CheckNonce { #[cfg(feature = "std")] fn fmt(&self, f: &mut sp_std::fmt::Formatter) -> sp_std::fmt::Result { write!(f, "CheckNonce({})", self.0) } #[cfg(not(feature = "std"))] fn fmt(&self, _: &mut sp_std::fmt::Formatter) -> sp_std::fmt::Result { Ok(()) } } impl SignedExtension for CheckNonce where T::Call: Dispatchable { type AccountId = T::AccountId; type Call = T::Call; type AdditionalSigned = (); type Pre = (); const IDENTIFIER: &'static str = "CheckNonce"; fn additional_signed(&self) -> sp_std::result::Result<(), TransactionValidityError> { Ok(()) } fn pre_dispatch( self, who: &Self::AccountId, _call: &Self::Call, _info: &DispatchInfoOf, _len: usize, ) -> Result<(), TransactionValidityError> { let mut account = Account::::get(who); if self.0 != account.nonce { return Err( if self.0 < account.nonce { InvalidTransaction::Stale } else { InvalidTransaction::Future }.into() ) } account.nonce += T::Index::one(); Account::::insert(who, account); Ok(()) } fn validate( &self, who: &Self::AccountId, _call: &Self::Call, info: &DispatchInfoOf, _len: usize, ) -> TransactionValidity { // check index let account = Account::::get(who); if self.0 < account.nonce { return InvalidTransaction::Stale.into() } let provides = vec![Encode::encode(&(who, self.0))]; let requires = if account.nonce < self.0 { vec![Encode::encode(&(who, self.0 - One::one()))] } else { vec![] }; Ok(ValidTransaction { priority: info.weight as TransactionPriority, requires, provides, longevity: TransactionLongevity::max_value(), propagate: true, }) } } impl IsDeadAccount for Module { fn is_dead_account(who: &T::AccountId) -> bool { !Account::::contains_key(who) } } /// Check for transaction mortality. #[derive(Encode, Decode, Clone, Eq, PartialEq)] pub struct CheckEra(Era, sp_std::marker::PhantomData); impl CheckEra { /// utility constructor. Used only in client/factory code. pub fn from(era: Era) -> Self { Self(era, sp_std::marker::PhantomData) } } impl Debug for CheckEra { #[cfg(feature = "std")] fn fmt(&self, f: &mut sp_std::fmt::Formatter) -> sp_std::fmt::Result { write!(f, "CheckEra({:?})", self.0) } #[cfg(not(feature = "std"))] fn fmt(&self, _: &mut sp_std::fmt::Formatter) -> sp_std::fmt::Result { Ok(()) } } impl SignedExtension for CheckEra { type AccountId = T::AccountId; type Call = T::Call; type AdditionalSigned = T::Hash; type Pre = (); const IDENTIFIER: &'static str = "CheckEra"; fn validate( &self, _who: &Self::AccountId, _call: &Self::Call, _info: &DispatchInfoOf, _len: usize, ) -> TransactionValidity { let current_u64 = >::block_number().saturated_into::(); let valid_till = self.0.death(current_u64); Ok(ValidTransaction { longevity: valid_till.saturating_sub(current_u64), ..Default::default() }) } fn additional_signed(&self) -> Result { let current_u64 = >::block_number().saturated_into::(); let n = self.0.birth(current_u64).saturated_into::(); if !>::contains_key(n) { Err(InvalidTransaction::AncientBirthBlock.into()) } else { Ok(>::block_hash(n)) } } } /// Nonce check and increment to give replay protection for transactions. #[derive(Encode, Decode, Clone, Eq, PartialEq)] pub struct CheckGenesis(sp_std::marker::PhantomData); impl Debug for CheckGenesis { #[cfg(feature = "std")] fn fmt(&self, f: &mut sp_std::fmt::Formatter) -> sp_std::fmt::Result { write!(f, "CheckGenesis") } #[cfg(not(feature = "std"))] fn fmt(&self, _: &mut sp_std::fmt::Formatter) -> sp_std::fmt::Result { Ok(()) } } impl CheckGenesis { /// Creates new `SignedExtension` to check genesis hash. pub fn new() -> Self { Self(sp_std::marker::PhantomData) } } impl SignedExtension for CheckGenesis { type AccountId = T::AccountId; type Call = ::Call; type AdditionalSigned = T::Hash; type Pre = (); const IDENTIFIER: &'static str = "CheckGenesis"; fn additional_signed(&self) -> Result { Ok(>::block_hash(T::BlockNumber::zero())) } } /// Ensure the runtime version registered in the transaction is the same as at present. #[derive(Encode, Decode, Clone, Eq, PartialEq)] pub struct CheckVersion(sp_std::marker::PhantomData); impl Debug for CheckVersion { #[cfg(feature = "std")] fn fmt(&self, f: &mut sp_std::fmt::Formatter) -> sp_std::fmt::Result { write!(f, "CheckVersion") } #[cfg(not(feature = "std"))] fn fmt(&self, _: &mut sp_std::fmt::Formatter) -> sp_std::fmt::Result { Ok(()) } } impl CheckVersion { /// Create new `SignedExtension` to check runtime version. pub fn new() -> Self { Self(sp_std::marker::PhantomData) } } impl SignedExtension for CheckVersion { type AccountId = T::AccountId; type Call = ::Call; type AdditionalSigned = u32; type Pre = (); const IDENTIFIER: &'static str = "CheckVersion"; fn additional_signed(&self) -> Result { Ok(>::runtime_version().spec_version) } } pub struct ChainContext(sp_std::marker::PhantomData); impl Default for ChainContext { fn default() -> Self { ChainContext(sp_std::marker::PhantomData) } } impl Lookup for ChainContext { type Source = ::Source; type Target = ::Target; fn lookup(&self, s: Self::Source) -> Result { ::lookup(s) } } #[cfg(test)] pub(crate) mod tests { use super::*; use sp_std::cell::RefCell; use sp_core::H256; use sp_runtime::{traits::{BlakeTwo256, IdentityLookup, SignedExtension}, testing::Header, DispatchError}; use frame_support::{impl_outer_origin, parameter_types, assert_ok, assert_err}; impl_outer_origin! { pub enum Origin for Test where system = super {} } #[derive(Clone, Eq, PartialEq, Debug)] pub struct Test; parameter_types! { pub const BlockHashCount: u64 = 10; pub const MaximumBlockWeight: Weight = 1024; pub const AvailableBlockRatio: Perbill = Perbill::from_percent(75); pub const MaximumBlockLength: u32 = 1024; pub const Version: RuntimeVersion = RuntimeVersion { spec_name: sp_version::create_runtime_str!("test"), impl_name: sp_version::create_runtime_str!("system-test"), authoring_version: 1, spec_version: 1, impl_version: 1, apis: sp_version::create_apis_vec!([]), transaction_version: 1, }; pub const BlockExecutionWeight: Weight = 10; pub const ExtrinsicBaseWeight: Weight = 5; pub const DbWeight: RuntimeDbWeight = RuntimeDbWeight { read: 10, write: 100, }; } thread_local!{ pub static KILLED: RefCell> = RefCell::new(vec![]); } pub struct RecordKilled; impl OnKilledAccount for RecordKilled { fn on_killed_account(who: &u64) { KILLED.with(|r| r.borrow_mut().push(*who)) } } #[derive(Debug, codec::Encode, codec::Decode)] pub struct Call; impl Dispatchable for Call { type Origin = (); type Trait = (); type Info = DispatchInfo; type PostInfo = PostDispatchInfo; fn dispatch(self, _origin: Self::Origin) -> sp_runtime::DispatchResultWithInfo { panic!("Do not use dummy implementation for dispatch."); } } impl Trait for Test { type Origin = Origin; type Call = Call; type Index = u64; type BlockNumber = u64; type Hash = H256; type Hashing = BlakeTwo256; type AccountId = u64; type Lookup = IdentityLookup; type Header = Header; type Event = u16; type BlockHashCount = BlockHashCount; type MaximumBlockWeight = MaximumBlockWeight; type DbWeight = DbWeight; type BlockExecutionWeight = BlockExecutionWeight; type ExtrinsicBaseWeight = ExtrinsicBaseWeight; type AvailableBlockRatio = AvailableBlockRatio; type MaximumBlockLength = MaximumBlockLength; type Version = Version; type ModuleToIndex = (); type AccountData = u32; type OnNewAccount = (); type OnKilledAccount = RecordKilled; } impl From> for u16 { fn from(e: Event) -> u16 { match e { Event::::ExtrinsicSuccess(..) => 100, Event::::ExtrinsicFailed(..) => 101, Event::::CodeUpdated => 102, _ => 103, } } } type System = Module; const CALL: &::Call = &Call; fn new_test_ext() -> sp_io::TestExternalities { let mut ext: sp_io::TestExternalities = GenesisConfig::default().build_storage::().unwrap().into(); // Add to each test the initial weight of a block ext.execute_with(|| System::register_extra_weight_unchecked(::BlockExecutionWeight::get())); ext } fn normal_weight_limit() -> Weight { ::AvailableBlockRatio::get() * ::MaximumBlockWeight::get() } fn normal_length_limit() -> u32 { ::AvailableBlockRatio::get() * ::MaximumBlockLength::get() } #[test] fn origin_works() { let o = Origin::from(RawOrigin::::Signed(1u64)); let x: Result, Origin> = o.into(); assert_eq!(x, Ok(RawOrigin::::Signed(1u64))); } #[test] fn stored_map_works() { new_test_ext().execute_with(|| { System::insert(&0, 42); assert!(System::allow_death(&0)); System::inc_ref(&0); assert!(!System::allow_death(&0)); System::insert(&0, 69); assert!(!System::allow_death(&0)); System::dec_ref(&0); assert!(System::allow_death(&0)); assert!(KILLED.with(|r| r.borrow().is_empty())); System::kill_account(&0); assert_eq!(KILLED.with(|r| r.borrow().clone()), vec![0u64]); }); } #[test] fn deposit_event_should_work() { new_test_ext().execute_with(|| { System::initialize( &1, &[0u8; 32].into(), &[0u8; 32].into(), &Default::default(), InitKind::Full, ); System::note_finished_extrinsics(); System::deposit_event(1u16); System::finalize(); assert_eq!( System::events(), vec![ EventRecord { phase: Phase::Finalization, event: 1u16, topics: vec![], } ] ); System::initialize( &2, &[0u8; 32].into(), &[0u8; 32].into(), &Default::default(), InitKind::Full, ); System::deposit_event(32u16); System::note_finished_initialize(); System::deposit_event(42u16); System::note_applied_extrinsic(&Ok(()), 0, Default::default()); System::note_applied_extrinsic(&Err(DispatchError::BadOrigin), 0, Default::default()); System::note_finished_extrinsics(); System::deposit_event(3u16); System::finalize(); assert_eq!( System::events(), vec![ EventRecord { phase: Phase::Initialization, event: 32u16, topics: vec![] }, EventRecord { phase: Phase::ApplyExtrinsic(0), event: 42u16, topics: vec![] }, EventRecord { phase: Phase::ApplyExtrinsic(0), event: 100u16, topics: vec![] }, EventRecord { phase: Phase::ApplyExtrinsic(1), event: 101u16, topics: vec![] }, EventRecord { phase: Phase::Finalization, event: 3u16, topics: vec![] } ] ); }); } #[test] fn deposit_event_topics() { new_test_ext().execute_with(|| { const BLOCK_NUMBER: u64 = 1; System::initialize( &BLOCK_NUMBER, &[0u8; 32].into(), &[0u8; 32].into(), &Default::default(), InitKind::Full, ); System::note_finished_extrinsics(); let topics = vec![ H256::repeat_byte(1), H256::repeat_byte(2), H256::repeat_byte(3), ]; // We deposit a few events with different sets of topics. System::deposit_event_indexed(&topics[0..3], 1u16); System::deposit_event_indexed(&topics[0..1], 2u16); System::deposit_event_indexed(&topics[1..2], 3u16); System::finalize(); // Check that topics are reflected in the event record. assert_eq!( System::events(), vec![ EventRecord { phase: Phase::Finalization, event: 1u16, topics: topics[0..3].to_vec(), }, EventRecord { phase: Phase::Finalization, event: 2u16, topics: topics[0..1].to_vec(), }, EventRecord { phase: Phase::Finalization, event: 3u16, topics: topics[1..2].to_vec(), } ] ); // Check that the topic-events mapping reflects the deposited topics. // Note that these are indexes of the events. assert_eq!( System::event_topics(&topics[0]), vec![(BLOCK_NUMBER, 0), (BLOCK_NUMBER, 1)], ); assert_eq!( System::event_topics(&topics[1]), vec![(BLOCK_NUMBER, 0), (BLOCK_NUMBER, 2)], ); assert_eq!( System::event_topics(&topics[2]), vec![(BLOCK_NUMBER, 0)], ); }); } #[test] fn prunes_block_hash_mappings() { new_test_ext().execute_with(|| { // simulate import of 15 blocks for n in 1..=15 { System::initialize( &n, &[n as u8 - 1; 32].into(), &[0u8; 32].into(), &Default::default(), InitKind::Full, ); System::finalize(); } // first 5 block hashes are pruned for n in 0..5 { assert_eq!( System::block_hash(n), H256::zero(), ); } // the remaining 10 are kept for n in 5..15 { assert_eq!( System::block_hash(n), [n as u8; 32].into(), ); } }) } #[test] fn signed_ext_check_nonce_works() { new_test_ext().execute_with(|| { Account::::insert(1, AccountInfo { nonce: 1, refcount: 0, data: 0 }); let info = DispatchInfo::default(); let len = 0_usize; // stale assert!(CheckNonce::(0).validate(&1, CALL, &info, len).is_err()); assert!(CheckNonce::(0).pre_dispatch(&1, CALL, &info, len).is_err()); // correct assert!(CheckNonce::(1).validate(&1, CALL, &info, len).is_ok()); assert!(CheckNonce::(1).pre_dispatch(&1, CALL, &info, len).is_ok()); // future assert!(CheckNonce::(5).validate(&1, CALL, &info, len).is_ok()); assert!(CheckNonce::(5).pre_dispatch(&1, CALL, &info, len).is_err()); }) } #[test] fn signed_ext_check_weight_works_normal_tx() { new_test_ext().execute_with(|| { let normal_limit = normal_weight_limit(); let small = DispatchInfo { weight: 100, ..Default::default() }; let medium = DispatchInfo { weight: normal_limit - ::ExtrinsicBaseWeight::get(), ..Default::default() }; let big = DispatchInfo { weight: normal_limit - ::ExtrinsicBaseWeight::get() + 1, ..Default::default() }; let len = 0_usize; let reset_check_weight = |i, f, s| { AllExtrinsicsWeight::put(s); let r = CheckWeight::(PhantomData).pre_dispatch(&1, CALL, i, len); if f { assert!(r.is_err()) } else { assert!(r.is_ok()) } }; reset_check_weight(&small, false, 0); reset_check_weight(&medium, false, 0); reset_check_weight(&big, true, 1); }) } #[test] fn signed_ext_check_weight_refund_works() { new_test_ext().execute_with(|| { // This is half of the max block weight let info = DispatchInfo { weight: 512, ..Default::default() }; let post_info = PostDispatchInfo { actual_weight: Some(128), }; let len = 0_usize; // We allow 75% for normal transaction, so we put 25% - extrinsic base weight AllExtrinsicsWeight::put(256 - ::ExtrinsicBaseWeight::get()); let pre = CheckWeight::(PhantomData).pre_dispatch(&1, CALL, &info, len).unwrap(); assert_eq!(AllExtrinsicsWeight::get().unwrap(), info.weight + 256); assert!( CheckWeight::::post_dispatch(pre, &info, &post_info, len, &Ok(())) .is_ok() ); assert_eq!( AllExtrinsicsWeight::get().unwrap(), post_info.actual_weight.unwrap() + 256, ); }) } #[test] fn signed_ext_check_weight_actual_weight_higher_than_max_is_capped() { new_test_ext().execute_with(|| { let info = DispatchInfo { weight: 512, ..Default::default() }; let post_info = PostDispatchInfo { actual_weight: Some(700), }; let len = 0_usize; AllExtrinsicsWeight::put(128); let pre = CheckWeight::(PhantomData).pre_dispatch(&1, CALL, &info, len).unwrap(); assert_eq!( AllExtrinsicsWeight::get().unwrap(), info.weight + 128 + ::ExtrinsicBaseWeight::get(), ); assert!( CheckWeight::::post_dispatch(pre, &info, &post_info, len, &Ok(())) .is_ok() ); assert_eq!( AllExtrinsicsWeight::get().unwrap(), info.weight + 128 + ::ExtrinsicBaseWeight::get(), ); }) } #[test] fn zero_weight_extrinsic_still_has_base_weight() { new_test_ext().execute_with(|| { let free = DispatchInfo { weight: 0, ..Default::default() }; let len = 0_usize; // Initial weight from `BlockExecutionWeight` assert_eq!(System::all_extrinsics_weight(), ::BlockExecutionWeight::get()); let r = CheckWeight::(PhantomData).pre_dispatch(&1, CALL, &free, len); assert!(r.is_ok()); assert_eq!( System::all_extrinsics_weight(), ::ExtrinsicBaseWeight::get() + ::BlockExecutionWeight::get() ); }) } #[test] fn max_extrinsic_weight_is_allowed_but_nothing_more() { // Dispatch Class Normal new_test_ext().execute_with(|| { let one = DispatchInfo { weight: 1, ..Default::default() }; let max = DispatchInfo { weight: System::max_extrinsic_weight(DispatchClass::Normal), ..Default::default() }; let len = 0_usize; assert_ok!(CheckWeight::::do_pre_dispatch(&max, len)); assert_err!( CheckWeight::::do_pre_dispatch(&one, len), InvalidTransaction::ExhaustsResources, ); // Weight should be 75% of 1024 (max block weight) assert_eq!(System::all_extrinsics_weight(), 768); }); // Dispatch Class Operational new_test_ext().execute_with(|| { let one = DispatchInfo { weight: 1, class: DispatchClass::Operational, ..Default::default() }; let max = DispatchInfo { weight: System::max_extrinsic_weight(DispatchClass::Operational), class: DispatchClass::Operational, ..Default::default() }; let len = 0_usize; assert_ok!(CheckWeight::::do_pre_dispatch(&max, len)); assert_err!( CheckWeight::::do_pre_dispatch(&one, len), InvalidTransaction::ExhaustsResources, ); // Weight should be 100% of max block weight assert_eq!(System::all_extrinsics_weight(), ::MaximumBlockWeight::get()); }); } #[test] fn mandatory_extrinsic_doesnt_care_about_limits() { new_test_ext().execute_with(|| { let max = DispatchInfo { weight: Weight::max_value(), class: DispatchClass::Mandatory, ..Default::default() }; let len = 0_usize; assert_ok!(CheckWeight::::do_pre_dispatch(&max, len)); assert_eq!(System::all_extrinsics_weight(), Weight::max_value()); assert!(System::all_extrinsics_weight() > ::MaximumBlockWeight::get()); }); } #[test] fn register_extra_weight_unchecked_doesnt_care_about_limits() { new_test_ext().execute_with(|| { System::register_extra_weight_unchecked(Weight::max_value()); assert_eq!(System::all_extrinsics_weight(), Weight::max_value()); assert!(System::all_extrinsics_weight() > ::MaximumBlockWeight::get()); }); } #[test] fn full_block_with_normal_and_operational() { new_test_ext().execute_with(|| { // Max block is 1024 // Max normal is 768 (75%) // 10 is taken for block execution weight // So normal extrinsic can be 758 weight (-5 for base extrinsic weight) // And Operational can be 256 to produce a full block (-5 for base) assert_eq!(System::max_extrinsic_weight(DispatchClass::Normal), 753); let max_normal = DispatchInfo { weight: 753, ..Default::default() }; let rest_operational = DispatchInfo { weight: 251, class: DispatchClass::Operational, ..Default::default() }; let len = 0_usize; assert_ok!(CheckWeight::::do_pre_dispatch(&max_normal, len)); assert_eq!(System::all_extrinsics_weight(), 768); assert_ok!(CheckWeight::::do_pre_dispatch(&rest_operational, len)); assert_eq!(::MaximumBlockWeight::get(), 1024); assert_eq!(System::all_extrinsics_weight(), ::MaximumBlockWeight::get()); }); } #[test] fn signed_ext_check_weight_works_operational_tx() { new_test_ext().execute_with(|| { let normal = DispatchInfo { weight: 100, ..Default::default() }; let op = DispatchInfo { weight: 100, class: DispatchClass::Operational, pays_fee: Pays::Yes }; let len = 0_usize; let normal_limit = normal_weight_limit(); // given almost full block AllExtrinsicsWeight::put(normal_limit); // will not fit. assert!(CheckWeight::(PhantomData).pre_dispatch(&1, CALL, &normal, len).is_err()); // will fit. assert!(CheckWeight::(PhantomData).pre_dispatch(&1, CALL, &op, len).is_ok()); // likewise for length limit. let len = 100_usize; AllExtrinsicsLen::put(normal_length_limit()); assert!(CheckWeight::(PhantomData).pre_dispatch(&1, CALL, &normal, len).is_err()); assert!(CheckWeight::(PhantomData).pre_dispatch(&1, CALL, &op, len).is_ok()); }) } #[test] fn signed_ext_check_weight_priority_works() { new_test_ext().execute_with(|| { let normal = DispatchInfo { weight: 100, class: DispatchClass::Normal, pays_fee: Pays::Yes }; let op = DispatchInfo { weight: 100, class: DispatchClass::Operational, pays_fee: Pays::Yes }; let len = 0_usize; let priority = CheckWeight::(PhantomData) .validate(&1, CALL, &normal, len) .unwrap() .priority; assert_eq!(priority, 100); let priority = CheckWeight::(PhantomData) .validate(&1, CALL, &op, len) .unwrap() .priority; assert_eq!(priority, u64::max_value()); }) } #[test] fn signed_ext_check_weight_block_size_works() { new_test_ext().execute_with(|| { let normal = DispatchInfo::default(); let normal_limit = normal_weight_limit() as usize; let reset_check_weight = |tx, s, f| { AllExtrinsicsLen::put(0); let r = CheckWeight::(PhantomData).pre_dispatch(&1, CALL, tx, s); if f { assert!(r.is_err()) } else { assert!(r.is_ok()) } }; reset_check_weight(&normal, normal_limit - 1, false); reset_check_weight(&normal, normal_limit, false); reset_check_weight(&normal, normal_limit + 1, true); // Operational ones don't have this limit. let op = DispatchInfo { weight: 0, class: DispatchClass::Operational, pays_fee: Pays::Yes }; reset_check_weight(&op, normal_limit, false); reset_check_weight(&op, normal_limit + 100, false); reset_check_weight(&op, 1024, false); reset_check_weight(&op, 1025, true); }) } #[test] fn signed_ext_check_era_should_work() { new_test_ext().execute_with(|| { // future assert_eq!( CheckEra::::from(Era::mortal(4, 2)).additional_signed().err().unwrap(), InvalidTransaction::AncientBirthBlock.into(), ); // correct System::set_block_number(13); >::insert(12, H256::repeat_byte(1)); assert!(CheckEra::::from(Era::mortal(4, 12)).additional_signed().is_ok()); }) } #[test] fn signed_ext_check_era_should_change_longevity() { new_test_ext().execute_with(|| { let normal = DispatchInfo { weight: 100, class: DispatchClass::Normal, pays_fee: Pays::Yes }; let len = 0_usize; let ext = ( CheckWeight::(PhantomData), CheckEra::::from(Era::mortal(16, 256)), ); System::set_block_number(17); >::insert(16, H256::repeat_byte(1)); assert_eq!(ext.validate(&1, CALL, &normal, len).unwrap().longevity, 15); }) } #[test] fn set_code_checks_works() { struct CallInWasm(Vec); impl sp_core::traits::CallInWasm for CallInWasm { fn call_in_wasm( &self, _: &[u8], _: Option>, _: &str, _: &[u8], _: &mut dyn sp_externalities::Externalities, _: sp_core::traits::MissingHostFunctions, ) -> Result, String> { Ok(self.0.clone()) } } let test_data = vec![ ("test", 1, 2, Err(Error::::SpecVersionNeedsToIncrease)), ("test", 1, 1, Err(Error::::SpecVersionNeedsToIncrease)), ("test2", 1, 1, Err(Error::::InvalidSpecName)), ("test", 2, 1, Ok(())), ("test", 0, 1, Err(Error::::SpecVersionNeedsToIncrease)), ("test", 1, 0, Err(Error::::SpecVersionNeedsToIncrease)), ]; for (spec_name, spec_version, impl_version, expected) in test_data.into_iter() { let version = RuntimeVersion { spec_name: spec_name.into(), spec_version, impl_version, ..Default::default() }; let call_in_wasm = CallInWasm(version.encode()); let mut ext = new_test_ext(); ext.register_extension(sp_core::traits::CallInWasmExt::new(call_in_wasm)); ext.execute_with(|| { let res = System::set_code( RawOrigin::Root.into(), vec![1, 2, 3, 4], ); assert_eq!(expected.map_err(DispatchError::from), res); }); } } #[test] fn set_code_with_real_wasm_blob() { let executor = substrate_test_runtime_client::new_native_executor(); let mut ext = new_test_ext(); ext.register_extension(sp_core::traits::CallInWasmExt::new(executor)); ext.execute_with(|| { System::set_block_number(1); System::set_code( RawOrigin::Root.into(), substrate_test_runtime_client::runtime::WASM_BINARY.to_vec(), ).unwrap(); assert_eq!( System::events(), vec![EventRecord { phase: Phase::Initialization, event: 102u16, topics: vec![] }], ); }); } #[test] fn runtime_upgraded_with_set_storage() { let executor = substrate_test_runtime_client::new_native_executor(); let mut ext = new_test_ext(); ext.register_extension(sp_core::traits::CallInWasmExt::new(executor)); ext.execute_with(|| { System::set_storage( RawOrigin::Root.into(), vec![( well_known_keys::CODE.to_vec(), substrate_test_runtime_client::runtime::WASM_BINARY.to_vec() )], ).unwrap(); }); } #[test] fn events_not_emitted_during_genesis() { new_test_ext().execute_with(|| { // Block Number is zero at genesis assert!(System::block_number().is_zero()); System::on_created_account(Default::default()); assert!(System::events().is_empty()); // Events will be emitted starting on block 1 System::set_block_number(1); System::on_created_account(Default::default()); assert!(System::events().len() == 1); }); } }