referrerpolicy=no-referrer-when-downgrade

rococo_parachain_runtime/
lib.rs

1// Copyright (C) Parity Technologies (UK) Ltd.
2// This file is part of Cumulus.
3// SPDX-License-Identifier: Apache-2.0
4
5// Licensed under the Apache License, Version 2.0 (the "License");
6// you may not use this file except in compliance with the License.
7// You may obtain a copy of the License at
8//
9// 	http://www.apache.org/licenses/LICENSE-2.0
10//
11// Unless required by applicable law or agreed to in writing, software
12// distributed under the License is distributed on an "AS IS" BASIS,
13// WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
14// See the License for the specific language governing permissions and
15// limitations under the License.
16
17#![cfg_attr(not(feature = "std"), no_std)]
18// `construct_runtime!` does a lot of recursion and requires us to increase the limit to 256.
19#![recursion_limit = "256"]
20
21// Make the WASM binary available.
22#[cfg(feature = "std")]
23include!(concat!(env!("OUT_DIR"), "/wasm_binary.rs"));
24
25mod genesis_config_presets;
26
27extern crate alloc;
28
29use alloc::vec::Vec;
30use cumulus_pallet_parachain_system::RelayNumberMonotonicallyIncreases;
31use polkadot_runtime_common::xcm_sender::NoPriceForMessageDelivery;
32use sp_api::impl_runtime_apis;
33use sp_core::OpaqueMetadata;
34use sp_runtime::{
35	generic, impl_opaque_keys,
36	traits::{AccountIdLookup, BlakeTwo256, Block as BlockT, Hash as HashT},
37	transaction_validity::{TransactionSource, TransactionValidity},
38	ApplyExtrinsicResult,
39};
40#[cfg(feature = "std")]
41use sp_version::NativeVersion;
42use sp_version::RuntimeVersion;
43
44// A few exports that help ease life for downstream crates.
45pub use frame_support::{
46	construct_runtime, derive_impl,
47	dispatch::DispatchClass,
48	genesis_builder_helper::{build_state, get_preset},
49	parameter_types,
50	traits::{
51		AsEnsureOriginWithArg, ConstBool, ConstU32, ConstU64, ConstU8, Contains, EitherOfDiverse,
52		Everything, IsInVec, Nothing, Randomness,
53	},
54	weights::{
55		constants::{
56			BlockExecutionWeight, ExtrinsicBaseWeight, RocksDbWeight, WEIGHT_REF_TIME_PER_SECOND,
57		},
58		ConstantMultiplier, IdentityFee, Weight,
59	},
60	StorageValue,
61};
62use frame_system::{
63	limits::{BlockLength, BlockWeights},
64	EnsureRoot, EnsureSigned,
65};
66pub use pallet_balances::Call as BalancesCall;
67pub use pallet_timestamp::Call as TimestampCall;
68pub use sp_consensus_aura::sr25519::AuthorityId as AuraId;
69#[cfg(any(feature = "std", test))]
70pub use sp_runtime::BuildStorage;
71pub use sp_runtime::{Perbill, Permill};
72
73use cumulus_primitives_core::{AggregateMessageOrigin, ParaId};
74use frame_support::traits::{Disabled, TransformOrigin};
75use parachains_common::{
76	impls::{AssetsFrom, NonZeroIssuance},
77	message_queue::{NarrowOriginToSibling, ParaIdToSibling},
78	AccountId, AssetIdForTrustBackedAssets, Signature,
79};
80use xcm_builder::{
81	AllowHrmpNotificationsFromRelayChain, AllowKnownQueryResponses, AllowSubscriptionsFrom,
82	AsPrefixedGeneralIndex, ConvertedConcreteId, FrameTransactionalProcessor, FungiblesAdapter,
83	LocalMint, TrailingSetTopicAsId, WithUniqueTopic,
84};
85use xcm_executor::traits::JustTry;
86
87// XCM imports
88use pallet_xcm::{EnsureXcm, IsMajorityOfBody, XcmPassthrough};
89use polkadot_parachain_primitives::primitives::Sibling;
90use xcm::latest::{prelude::*, ROCOCO_GENESIS_HASH};
91use xcm_builder::{
92	AccountId32Aliases, AllowExplicitUnpaidExecutionFrom, AllowTopLevelPaidExecutionFrom,
93	EnsureXcmOrigin, FixedWeightBounds, FungibleAdapter, IsConcrete, NativeAsset,
94	ParentAsSuperuser, ParentIsPreset, RelayChainAsNative, SiblingParachainAsNative,
95	SiblingParachainConvertsVia, SignedAccountId32AsNative, SignedToAccountId32,
96	SovereignSignedViaLocation, TakeWeightCredit, UsingComponents,
97};
98use xcm_executor::XcmExecutor;
99
100pub type SessionHandlers = ();
101
102impl_opaque_keys! {
103	pub struct SessionKeys {
104		pub aura: Aura,
105	}
106}
107
108/// This runtime version.
109#[sp_version::runtime_version]
110pub const VERSION: RuntimeVersion = RuntimeVersion {
111	spec_name: alloc::borrow::Cow::Borrowed("test-parachain"),
112	impl_name: alloc::borrow::Cow::Borrowed("test-parachain"),
113	authoring_version: 1,
114	spec_version: 1_014_000,
115	impl_version: 0,
116	apis: RUNTIME_API_VERSIONS,
117	transaction_version: 6,
118	system_version: 0,
119};
120
121pub const MILLISECS_PER_BLOCK: u64 = 6000;
122
123pub const SLOT_DURATION: u64 = MILLISECS_PER_BLOCK;
124
125pub const EPOCH_DURATION_IN_BLOCKS: u32 = 10 * MINUTES;
126
127// These time units are defined in number of blocks.
128pub const MINUTES: BlockNumber = 60_000 / (MILLISECS_PER_BLOCK as BlockNumber);
129pub const HOURS: BlockNumber = MINUTES * 60;
130pub const DAYS: BlockNumber = HOURS * 24;
131
132pub const ROC: Balance = 1_000_000_000_000;
133pub const MILLIROC: Balance = 1_000_000_000;
134pub const MICROROC: Balance = 1_000_000;
135
136// 1 in 4 blocks (on average, not counting collisions) will be primary babe blocks.
137pub const PRIMARY_PROBABILITY: (u64, u64) = (1, 4);
138
139/// The version information used to identify this runtime when compiled natively.
140#[cfg(feature = "std")]
141pub fn native_version() -> NativeVersion {
142	NativeVersion { runtime_version: VERSION, can_author_with: Default::default() }
143}
144
145/// We assume that ~10% of the block weight is consumed by `on_initialize` handlers.
146/// This is used to limit the maximal weight of a single extrinsic.
147const AVERAGE_ON_INITIALIZE_RATIO: Perbill = Perbill::from_percent(10);
148/// We allow `Normal` extrinsics to fill up the block up to 75%, the rest can be used
149/// by  Operational  extrinsics.
150const NORMAL_DISPATCH_RATIO: Perbill = Perbill::from_percent(75);
151/// We allow for 2 seconds of compute with a 6 second average block time.
152const MAXIMUM_BLOCK_WEIGHT: Weight = Weight::from_parts(
153	WEIGHT_REF_TIME_PER_SECOND.saturating_mul(2),
154	cumulus_primitives_core::relay_chain::MAX_POV_SIZE as u64,
155);
156
157/// Maximum number of blocks simultaneously accepted by the Runtime, not yet included
158/// into the relay chain.
159const UNINCLUDED_SEGMENT_CAPACITY: u32 = 3;
160/// How many parachain blocks are processed by the relay chain per parent. Limits the
161/// number of blocks authored per slot.
162const BLOCK_PROCESSING_VELOCITY: u32 = 2;
163/// Relay chain slot duration, in milliseconds.
164const RELAY_CHAIN_SLOT_DURATION_MILLIS: u32 = 6000;
165
166parameter_types! {
167	pub const BlockHashCount: BlockNumber = 250;
168	pub const Version: RuntimeVersion = VERSION;
169	pub RuntimeBlockLength: BlockLength =
170		BlockLength::max_with_normal_ratio(5 * 1024 * 1024, NORMAL_DISPATCH_RATIO);
171	pub RuntimeBlockWeights: BlockWeights = BlockWeights::builder()
172		.base_block(BlockExecutionWeight::get())
173		.for_class(DispatchClass::all(), |weights| {
174			weights.base_extrinsic = ExtrinsicBaseWeight::get();
175		})
176		.for_class(DispatchClass::Normal, |weights| {
177			weights.max_total = Some(NORMAL_DISPATCH_RATIO * MAXIMUM_BLOCK_WEIGHT);
178		})
179		.for_class(DispatchClass::Operational, |weights| {
180			weights.max_total = Some(MAXIMUM_BLOCK_WEIGHT);
181			// Operational transactions have some extra reserved space, so that they
182			// are included even if block reached `MAXIMUM_BLOCK_WEIGHT`.
183			weights.reserved = Some(
184				MAXIMUM_BLOCK_WEIGHT - NORMAL_DISPATCH_RATIO * MAXIMUM_BLOCK_WEIGHT
185			);
186		})
187		.avg_block_initialization(AVERAGE_ON_INITIALIZE_RATIO)
188		.build_or_panic();
189	pub const SS58Prefix: u8 = 42;
190}
191
192#[derive_impl(frame_system::config_preludes::TestDefaultConfig)]
193impl frame_system::Config for Runtime {
194	/// The identifier used to distinguish between accounts.
195	type AccountId = AccountId;
196	/// The aggregated dispatch type that is available for extrinsics.
197	type RuntimeCall = RuntimeCall;
198	/// The lookup mechanism to get account ID from whatever is passed in dispatchers.
199	type Lookup = AccountIdLookup<AccountId, ()>;
200	/// The index type for storing how many extrinsics an account has signed.
201	type Nonce = Nonce;
202	/// The type for hashing blocks and tries.
203	type Hash = Hash;
204	/// The hashing algorithm used.
205	type Hashing = BlakeTwo256;
206	/// The block type.
207	type Block = Block;
208	/// The ubiquitous event type.
209	type RuntimeEvent = RuntimeEvent;
210	/// The ubiquitous origin type.
211	type RuntimeOrigin = RuntimeOrigin;
212	/// Maximum number of block number to block hash mappings to keep (oldest pruned first).
213	type BlockHashCount = BlockHashCount;
214	/// Runtime version.
215	type Version = Version;
216	/// Converts a module to an index of this module in the runtime.
217	type PalletInfo = PalletInfo;
218	type AccountData = pallet_balances::AccountData<Balance>;
219	type OnNewAccount = ();
220	type OnKilledAccount = ();
221	type DbWeight = RocksDbWeight;
222	type BaseCallFilter = frame_support::traits::Everything;
223	type SystemWeightInfo = ();
224	type BlockWeights = RuntimeBlockWeights;
225	type BlockLength = RuntimeBlockLength;
226	type SS58Prefix = SS58Prefix;
227	type OnSetCode = cumulus_pallet_parachain_system::ParachainSetCode<Self>;
228	type MaxConsumers = frame_support::traits::ConstU32<16>;
229	type SingleBlockMigrations = RemoveCollectiveFlip;
230}
231
232impl cumulus_pallet_weight_reclaim::Config for Runtime {
233	type WeightInfo = ();
234}
235
236impl pallet_timestamp::Config for Runtime {
237	/// A timestamp: milliseconds since the unix epoch.
238	type Moment = u64;
239	type OnTimestampSet = Aura;
240	type MinimumPeriod = ConstU64<0>;
241	type WeightInfo = ();
242}
243
244parameter_types! {
245	pub const ExistentialDeposit: u128 = MILLIROC;
246	pub const TransferFee: u128 = MILLIROC;
247	pub const CreationFee: u128 = MILLIROC;
248	pub const TransactionByteFee: u128 = MICROROC;
249}
250
251impl pallet_balances::Config for Runtime {
252	/// The type for recording an account's balance.
253	type Balance = Balance;
254	type DustRemoval = ();
255	/// The ubiquitous event type.
256	type RuntimeEvent = RuntimeEvent;
257	type ExistentialDeposit = ExistentialDeposit;
258	type AccountStore = System;
259	type WeightInfo = ();
260	type MaxLocks = ConstU32<50>;
261	type MaxReserves = ConstU32<50>;
262	type ReserveIdentifier = [u8; 8];
263	type RuntimeHoldReason = RuntimeHoldReason;
264	type RuntimeFreezeReason = RuntimeFreezeReason;
265	type FreezeIdentifier = ();
266	type MaxFreezes = ConstU32<0>;
267	type DoneSlashHandler = ();
268}
269
270impl pallet_transaction_payment::Config for Runtime {
271	type RuntimeEvent = RuntimeEvent;
272	type OnChargeTransaction = pallet_transaction_payment::FungibleAdapter<Balances, ()>;
273	type WeightToFee = IdentityFee<Balance>;
274	type LengthToFee = ConstantMultiplier<Balance, TransactionByteFee>;
275	type FeeMultiplierUpdate = ();
276	type OperationalFeeMultiplier = ConstU8<5>;
277	type WeightInfo = ();
278}
279
280impl pallet_sudo::Config for Runtime {
281	type RuntimeCall = RuntimeCall;
282	type RuntimeEvent = RuntimeEvent;
283	type WeightInfo = pallet_sudo::weights::SubstrateWeight<Runtime>;
284}
285
286parameter_types! {
287	pub const ReservedXcmpWeight: Weight = MAXIMUM_BLOCK_WEIGHT.saturating_div(4);
288	pub const ReservedDmpWeight: Weight = MAXIMUM_BLOCK_WEIGHT.saturating_div(4);
289	pub const RelayOrigin: AggregateMessageOrigin = AggregateMessageOrigin::Parent;
290}
291
292type ConsensusHook = cumulus_pallet_aura_ext::FixedVelocityConsensusHook<
293	Runtime,
294	RELAY_CHAIN_SLOT_DURATION_MILLIS,
295	BLOCK_PROCESSING_VELOCITY,
296	UNINCLUDED_SEGMENT_CAPACITY,
297>;
298
299impl cumulus_pallet_parachain_system::Config for Runtime {
300	type WeightInfo = ();
301	type RuntimeEvent = RuntimeEvent;
302	type OnSystemEvent = ();
303	type SelfParaId = parachain_info::Pallet<Runtime>;
304	type OutboundXcmpMessageSource = XcmpQueue;
305	type DmpQueue = frame_support::traits::EnqueueWithOrigin<MessageQueue, RelayOrigin>;
306	type ReservedDmpWeight = ReservedDmpWeight;
307	type XcmpMessageHandler = XcmpQueue;
308	type ReservedXcmpWeight = ReservedXcmpWeight;
309	type CheckAssociatedRelayNumber = RelayNumberMonotonicallyIncreases;
310	type ConsensusHook = ConsensusHook;
311	type RelayParentOffset = ConstU32<0>;
312}
313
314impl parachain_info::Config for Runtime {}
315
316parameter_types! {
317	pub MessageQueueServiceWeight: Weight = Perbill::from_percent(35) * RuntimeBlockWeights::get().max_block;
318}
319
320impl pallet_message_queue::Config for Runtime {
321	type RuntimeEvent = RuntimeEvent;
322	type WeightInfo = ();
323	type MessageProcessor = xcm_builder::ProcessXcmMessage<
324		AggregateMessageOrigin,
325		xcm_executor::XcmExecutor<XcmConfig>,
326		RuntimeCall,
327	>;
328	type Size = u32;
329	// The XCMP queue pallet is only ever able to handle the `Sibling(ParaId)` origin:
330	type QueueChangeHandler = NarrowOriginToSibling<XcmpQueue>;
331	type QueuePausedQuery = NarrowOriginToSibling<XcmpQueue>;
332	type HeapSize = sp_core::ConstU32<{ 103 * 1024 }>;
333	type MaxStale = sp_core::ConstU32<8>;
334	type ServiceWeight = MessageQueueServiceWeight;
335	type IdleMaxServiceWeight = ();
336}
337
338impl cumulus_pallet_aura_ext::Config for Runtime {}
339
340parameter_types! {
341	pub const RocLocation: Location = Location::parent();
342	pub const RococoNetwork: NetworkId = NetworkId::ByGenesis(ROCOCO_GENESIS_HASH);
343	pub RelayChainOrigin: RuntimeOrigin = cumulus_pallet_xcm::Origin::Relay.into();
344	pub UniversalLocation: InteriorLocation = [GlobalConsensus(RococoNetwork::get()), Parachain(ParachainInfo::parachain_id().into())].into();
345	pub CheckingAccount: AccountId = PolkadotXcm::check_account();
346}
347
348/// Type for specifying how a `Location` can be converted into an `AccountId`. This is used
349/// when determining ownership of accounts for asset transacting and when attempting to use XCM
350/// `Transact` in order to determine the dispatch Origin.
351pub type LocationToAccountId = (
352	// The parent (Relay-chain) origin converts to the parent `AccountId`.
353	ParentIsPreset<AccountId>,
354	// Sibling parachain origins convert to AccountId via the `ParaId::into`.
355	SiblingParachainConvertsVia<Sibling, AccountId>,
356	// Straight up local `AccountId32` origins just alias directly to `AccountId`.
357	AccountId32Aliases<RococoNetwork, AccountId>,
358);
359
360/// Means for transacting assets on this chain.
361pub type FungibleTransactor = FungibleAdapter<
362	// Use this currency:
363	Balances,
364	// Use this currency when it is a fungible asset matching the given location or name:
365	IsConcrete<RocLocation>,
366	// Do a simple punn to convert an AccountId32 Location into a native chain account ID:
367	LocationToAccountId,
368	// Our chain's account ID type (we can't get away without mentioning it explicitly):
369	AccountId,
370	// We don't track any teleports.
371	(),
372>;
373
374/// Means for transacting assets besides the native currency on this chain.
375pub type FungiblesTransactor = FungiblesAdapter<
376	// Use this fungibles implementation:
377	Assets,
378	// Use this currency when it is a fungible asset matching the given location or name:
379	ConvertedConcreteId<
380		AssetIdForTrustBackedAssets,
381		u64,
382		AsPrefixedGeneralIndex<
383			SystemAssetHubAssetsPalletLocation,
384			AssetIdForTrustBackedAssets,
385			JustTry,
386		>,
387		JustTry,
388	>,
389	// Convert an XCM Location into a local account id:
390	LocationToAccountId,
391	// Our chain's account ID type (we can't get away without mentioning it explicitly):
392	AccountId,
393	// We only want to allow teleports of known assets. We use non-zero issuance as an indication
394	// that this asset is known.
395	LocalMint<NonZeroIssuance<AccountId, Assets>>,
396	// The account to use for tracking teleports.
397	CheckingAccount,
398>;
399/// Means for transacting assets on this chain.
400pub type AssetTransactors = (FungibleTransactor, FungiblesTransactor);
401
402/// This is the type we use to convert an (incoming) XCM origin into a local `Origin` instance,
403/// ready for dispatching a transaction with Xcm's `Transact`. There is an `OriginKind` which can
404/// biases the kind of local `Origin` it will become.
405pub type XcmOriginToTransactDispatchOrigin = (
406	// Sovereign account converter; this attempts to derive an `AccountId` from the origin location
407	// using `LocationToAccountId` and then turn that into the usual `Signed` origin. Useful for
408	// foreign chains who want to have a local sovereign account on this chain which they control.
409	SovereignSignedViaLocation<LocationToAccountId, RuntimeOrigin>,
410	// Native converter for Relay-chain (Parent) location; will convert to a `Relay` origin when
411	// recognised.
412	RelayChainAsNative<RelayChainOrigin, RuntimeOrigin>,
413	// Native converter for sibling Parachains; will convert to a `SiblingPara` origin when
414	// recognised.
415	SiblingParachainAsNative<cumulus_pallet_xcm::Origin, RuntimeOrigin>,
416	// Superuser converter for the Relay-chain (Parent) location. This will allow it to issue a
417	// transaction from the Root origin.
418	ParentAsSuperuser<RuntimeOrigin>,
419	// Native signed account converter; this just converts an `AccountId32` origin into a normal
420	// `RuntimeOrigin::Signed` origin of the same 32-byte value.
421	SignedAccountId32AsNative<RococoNetwork, RuntimeOrigin>,
422	// Xcm origins can be represented natively under the Xcm pallet's Xcm origin.
423	XcmPassthrough<RuntimeOrigin>,
424);
425
426parameter_types! {
427	// One XCM operation is 1_000_000_000 weight - almost certainly a conservative estimate.
428	pub UnitWeightCost: Weight = Weight::from_parts(1_000_000_000, 64 * 1024);
429	// One ROC buys 1 second of weight.
430	pub const WeightPrice: (Location, u128) = (Location::parent(), ROC);
431	pub const MaxInstructions: u32 = 100;
432}
433
434pub struct ParentOrParentsUnitPlurality;
435impl Contains<Location> for ParentOrParentsUnitPlurality {
436	fn contains(location: &Location) -> bool {
437		matches!(location.unpack(), (1, []) | (1, [Plurality { id: BodyId::Unit, .. }]))
438	}
439}
440
441pub struct AssetHub;
442impl Contains<Location> for AssetHub {
443	fn contains(location: &Location) -> bool {
444		matches!(location.unpack(), (1, [Parachain(1000)]))
445	}
446}
447
448pub type Barrier = TrailingSetTopicAsId<(
449	TakeWeightCredit,
450	AllowTopLevelPaidExecutionFrom<Everything>,
451	// Parent & its unit plurality gets free execution.
452	AllowExplicitUnpaidExecutionFrom<ParentOrParentsUnitPlurality>,
453	// The network's Asset Hub gets free execution.
454	AllowExplicitUnpaidExecutionFrom<AssetHub>,
455	// Expected responses are OK.
456	AllowKnownQueryResponses<PolkadotXcm>,
457	// Subscriptions for version tracking are OK.
458	AllowSubscriptionsFrom<Everything>,
459	// HRMP notifications from the relay chain are OK.
460	AllowHrmpNotificationsFromRelayChain,
461)>;
462
463parameter_types! {
464	pub MaxAssetsIntoHolding: u32 = 64;
465	pub SystemAssetHubLocation: Location = Location::new(1, [Parachain(1000)]);
466	// ALWAYS ensure that the index in PalletInstance stays up-to-date with
467	// the Relay Chain's Asset Hub's Assets pallet index
468	pub SystemAssetHubAssetsPalletLocation: Location =
469		Location::new(1, [Parachain(1000), PalletInstance(50)]);
470}
471
472pub type Reserves = (NativeAsset, AssetsFrom<SystemAssetHubLocation>);
473
474pub struct XcmConfig;
475impl xcm_executor::Config for XcmConfig {
476	type RuntimeCall = RuntimeCall;
477	type XcmSender = XcmRouter;
478	type XcmEventEmitter = PolkadotXcm;
479	// How to withdraw and deposit an asset.
480	type AssetTransactor = AssetTransactors;
481	type OriginConverter = XcmOriginToTransactDispatchOrigin;
482	type IsReserve = Reserves;
483	type IsTeleporter = NativeAsset; // <- should be enough to allow teleportation of ROC
484	type UniversalLocation = UniversalLocation;
485	type Barrier = Barrier;
486	type Weigher = FixedWeightBounds<UnitWeightCost, RuntimeCall, MaxInstructions>;
487	type Trader = UsingComponents<IdentityFee<Balance>, RocLocation, AccountId, Balances, ()>;
488	type ResponseHandler = PolkadotXcm;
489	type AssetTrap = PolkadotXcm;
490	type AssetClaims = PolkadotXcm;
491	type SubscriptionService = PolkadotXcm;
492	type PalletInstancesInfo = AllPalletsWithSystem;
493	type MaxAssetsIntoHolding = MaxAssetsIntoHolding;
494	type AssetLocker = ();
495	type AssetExchanger = ();
496	type FeeManager = ();
497	type MessageExporter = ();
498	type UniversalAliases = Nothing;
499	type CallDispatcher = RuntimeCall;
500	type SafeCallFilter = Everything;
501	type Aliasers = Nothing;
502	type TransactionalProcessor = FrameTransactionalProcessor;
503	type HrmpNewChannelOpenRequestHandler = ();
504	type HrmpChannelAcceptedHandler = ();
505	type HrmpChannelClosingHandler = ();
506	type XcmRecorder = PolkadotXcm;
507}
508
509/// Converts a local signed origin into an XCM location. Forms the basis for local origins
510/// sending/executing XCMs.
511pub type LocalOriginToLocation = SignedToAccountId32<RuntimeOrigin, AccountId, RococoNetwork>;
512
513/// The means for routing XCM messages which are not for local execution into the right message
514/// queues.
515pub type XcmRouter = WithUniqueTopic<(
516	// Two routers - use UMP to communicate with the relay chain:
517	cumulus_primitives_utility::ParentAsUmp<ParachainSystem, (), ()>,
518	// ..and XCMP to communicate with the sibling chains.
519	XcmpQueue,
520)>;
521
522impl pallet_xcm::Config for Runtime {
523	type RuntimeEvent = RuntimeEvent;
524	type SendXcmOrigin = EnsureXcmOrigin<RuntimeOrigin, LocalOriginToLocation>;
525	type XcmRouter = XcmRouter;
526	type ExecuteXcmOrigin = EnsureXcmOrigin<RuntimeOrigin, LocalOriginToLocation>;
527	type XcmExecuteFilter = Everything;
528	type XcmExecutor = XcmExecutor<XcmConfig>;
529	type XcmTeleportFilter = Everything;
530	type XcmReserveTransferFilter = Nothing;
531	type Weigher = FixedWeightBounds<UnitWeightCost, RuntimeCall, MaxInstructions>;
532	type UniversalLocation = UniversalLocation;
533	type RuntimeOrigin = RuntimeOrigin;
534	type RuntimeCall = RuntimeCall;
535	const VERSION_DISCOVERY_QUEUE_SIZE: u32 = 100;
536	type AdvertisedXcmVersion = pallet_xcm::CurrentXcmVersion;
537	type Currency = Balances;
538	type CurrencyMatcher = ();
539	type TrustedLockers = ();
540	type SovereignAccountOf = LocationToAccountId;
541	type MaxLockers = ConstU32<8>;
542	type WeightInfo = pallet_xcm::TestWeightInfo;
543	type AdminOrigin = EnsureRoot<AccountId>;
544	type MaxRemoteLockConsumers = ConstU32<0>;
545	type RemoteLockConsumerIdentifier = ();
546	// Aliasing is disabled: xcm_executor::Config::Aliasers is set to `Nothing`.
547	type AuthorizedAliasConsideration = Disabled;
548}
549
550impl cumulus_pallet_xcm::Config for Runtime {
551	type RuntimeEvent = RuntimeEvent;
552	type XcmExecutor = XcmExecutor<XcmConfig>;
553}
554
555impl cumulus_pallet_xcmp_queue::Config for Runtime {
556	type RuntimeEvent = RuntimeEvent;
557	type ChannelInfo = ParachainSystem;
558	type VersionWrapper = ();
559	// Enqueue XCMP messages from siblings for later processing.
560	type XcmpQueue = TransformOrigin<MessageQueue, AggregateMessageOrigin, ParaId, ParaIdToSibling>;
561	type MaxInboundSuspended = ConstU32<1_000>;
562	type MaxActiveOutboundChannels = ConstU32<128>;
563	// Most on-chain HRMP channels are configured to use 102400 bytes of max message size, so we
564	// need to set the page size larger than that until we reduce the channel size on-chain.
565	type MaxPageSize = ConstU32<{ 103 * 1024 }>;
566	type ControllerOrigin = EnsureRoot<AccountId>;
567	type ControllerOriginConverter = XcmOriginToTransactDispatchOrigin;
568	type WeightInfo = cumulus_pallet_xcmp_queue::weights::SubstrateWeight<Runtime>;
569	type PriceForSiblingDelivery = NoPriceForMessageDelivery<ParaId>;
570}
571
572impl cumulus_ping::Config for Runtime {
573	type RuntimeEvent = RuntimeEvent;
574	type RuntimeOrigin = RuntimeOrigin;
575	type RuntimeCall = RuntimeCall;
576	type XcmSender = XcmRouter;
577}
578
579parameter_types! {
580	pub const AssetDeposit: Balance = ROC;
581	pub const AssetAccountDeposit: Balance = ROC;
582	pub const ApprovalDeposit: Balance = 100 * MILLIROC;
583	pub const AssetsStringLimit: u32 = 50;
584	pub const MetadataDepositBase: Balance = ROC;
585	pub const MetadataDepositPerByte: Balance = 10 * MILLIROC;
586	pub const UnitBody: BodyId = BodyId::Unit;
587}
588
589/// A majority of the Unit body from Rococo over XCM is our required administration origin.
590pub type AdminOrigin =
591	EitherOfDiverse<EnsureRoot<AccountId>, EnsureXcm<IsMajorityOfBody<RocLocation, UnitBody>>>;
592
593impl pallet_assets::Config for Runtime {
594	type RuntimeEvent = RuntimeEvent;
595	type Balance = u64;
596	type AssetId = AssetIdForTrustBackedAssets;
597	type AssetIdParameter = codec::Compact<AssetIdForTrustBackedAssets>;
598	type Currency = Balances;
599	type CreateOrigin = AsEnsureOriginWithArg<EnsureSigned<AccountId>>;
600	type ForceOrigin = AdminOrigin;
601	type AssetDeposit = AssetDeposit;
602	type MetadataDepositBase = MetadataDepositBase;
603	type MetadataDepositPerByte = MetadataDepositPerByte;
604	type ApprovalDeposit = ApprovalDeposit;
605	type StringLimit = AssetsStringLimit;
606	type Holder = ();
607	type Freezer = ();
608	type Extra = ();
609	type WeightInfo = pallet_assets::weights::SubstrateWeight<Runtime>;
610	type CallbackHandle = ();
611	type AssetAccountDeposit = AssetAccountDeposit;
612	type RemoveItemsLimit = frame_support::traits::ConstU32<1000>;
613	#[cfg(feature = "runtime-benchmarks")]
614	type BenchmarkHelper = ();
615}
616
617impl pallet_aura::Config for Runtime {
618	type AuthorityId = AuraId;
619	type DisabledValidators = ();
620	type MaxAuthorities = ConstU32<100_000>;
621	type AllowMultipleBlocksPerSlot = ConstBool<true>;
622	type SlotDuration = ConstU64<SLOT_DURATION>;
623}
624
625construct_runtime! {
626	pub enum Runtime
627	{
628		System: frame_system,
629		Timestamp: pallet_timestamp,
630		Sudo: pallet_sudo,
631		TransactionPayment: pallet_transaction_payment,
632		WeightReclaim: cumulus_pallet_weight_reclaim,
633
634		ParachainSystem: cumulus_pallet_parachain_system = 20,
635		ParachainInfo: parachain_info = 21,
636
637		Balances: pallet_balances = 30,
638		Assets: pallet_assets = 31,
639
640		Aura: pallet_aura,
641		AuraExt: cumulus_pallet_aura_ext,
642
643		// XCM helpers.
644		XcmpQueue: cumulus_pallet_xcmp_queue = 50,
645		PolkadotXcm: pallet_xcm = 51,
646		CumulusXcm: cumulus_pallet_xcm = 52,
647		// RIP DmpQueue 53
648		MessageQueue: pallet_message_queue = 54,
649
650		Spambot: cumulus_ping = 99,
651	}
652}
653
654/// Balance of an account.
655pub type Balance = u128;
656/// Index of a transaction in the chain.
657pub type Nonce = u32;
658/// A hash of some data used by the chain.
659pub type Hash = <BlakeTwo256 as HashT>::Output;
660/// An index to a block.
661pub type BlockNumber = u32;
662/// The address format for describing accounts.
663pub type Address = sp_runtime::MultiAddress<AccountId, ()>;
664/// Block header type as expected by this runtime.
665pub type Header = generic::Header<BlockNumber, BlakeTwo256>;
666/// Block type as expected by this runtime.
667pub type Block = generic::Block<Header, UncheckedExtrinsic>;
668/// A Block signed with a Justification
669pub type SignedBlock = generic::SignedBlock<Block>;
670/// BlockId type as expected by this runtime.
671pub type BlockId = generic::BlockId<Block>;
672/// The extension to the basic transaction logic.
673pub type TxExtension = cumulus_pallet_weight_reclaim::StorageWeightReclaim<
674	Runtime,
675	(
676		frame_system::AuthorizeCall<Runtime>,
677		frame_system::CheckNonZeroSender<Runtime>,
678		frame_system::CheckSpecVersion<Runtime>,
679		frame_system::CheckTxVersion<Runtime>,
680		frame_system::CheckGenesis<Runtime>,
681		frame_system::CheckEra<Runtime>,
682		frame_system::CheckNonce<Runtime>,
683		frame_system::CheckWeight<Runtime>,
684		pallet_transaction_payment::ChargeTransactionPayment<Runtime>,
685	),
686>;
687
688/// Unchecked extrinsic type as expected by this runtime.
689pub type UncheckedExtrinsic =
690	generic::UncheckedExtrinsic<Address, RuntimeCall, Signature, TxExtension>;
691/// Executive: handles dispatch to the various modules.
692pub type Executive = frame_executive::Executive<
693	Runtime,
694	Block,
695	frame_system::ChainContext<Runtime>,
696	Runtime,
697	AllPalletsWithSystem,
698>;
699
700pub struct RemoveCollectiveFlip;
701impl frame_support::traits::OnRuntimeUpgrade for RemoveCollectiveFlip {
702	fn on_runtime_upgrade() -> Weight {
703		use frame_support::storage::migration;
704		// Remove the storage value `RandomMaterial` from removed pallet `RandomnessCollectiveFlip`
705		#[allow(deprecated)]
706		migration::remove_storage_prefix(b"RandomnessCollectiveFlip", b"RandomMaterial", b"");
707		<Runtime as frame_system::Config>::DbWeight::get().writes(1)
708	}
709}
710
711impl_runtime_apis! {
712	impl sp_api::Core<Block> for Runtime {
713		fn version() -> RuntimeVersion {
714			VERSION
715		}
716
717		fn execute_block(block: Block) {
718			Executive::execute_block(block);
719		}
720
721		fn initialize_block(header: &<Block as BlockT>::Header) -> sp_runtime::ExtrinsicInclusionMode {
722			Executive::initialize_block(header)
723		}
724	}
725
726	impl sp_api::Metadata<Block> for Runtime {
727		fn metadata() -> OpaqueMetadata {
728			OpaqueMetadata::new(Runtime::metadata().into())
729		}
730
731		fn metadata_at_version(version: u32) -> Option<OpaqueMetadata> {
732			Runtime::metadata_at_version(version)
733		}
734
735		fn metadata_versions() -> alloc::vec::Vec<u32> {
736			Runtime::metadata_versions()
737		}
738	}
739
740	impl sp_block_builder::BlockBuilder<Block> for Runtime {
741		fn apply_extrinsic(
742			extrinsic: <Block as BlockT>::Extrinsic,
743		) -> ApplyExtrinsicResult {
744			Executive::apply_extrinsic(extrinsic)
745		}
746
747		fn finalize_block() -> <Block as BlockT>::Header {
748			Executive::finalize_block()
749		}
750
751		fn inherent_extrinsics(data: sp_inherents::InherentData) -> Vec<<Block as BlockT>::Extrinsic> {
752			data.create_extrinsics()
753		}
754
755		fn check_inherents(block: Block, data: sp_inherents::InherentData) -> sp_inherents::CheckInherentsResult {
756			data.check_extrinsics(&block)
757		}
758	}
759
760	impl sp_transaction_pool::runtime_api::TaggedTransactionQueue<Block> for Runtime {
761		fn validate_transaction(
762			source: TransactionSource,
763			tx: <Block as BlockT>::Extrinsic,
764			block_hash: <Block as BlockT>::Hash,
765		) -> TransactionValidity {
766			Executive::validate_transaction(source, tx, block_hash)
767		}
768	}
769
770	impl sp_offchain::OffchainWorkerApi<Block> for Runtime {
771		fn offchain_worker(header: &<Block as BlockT>::Header) {
772			Executive::offchain_worker(header)
773		}
774	}
775
776	impl sp_session::SessionKeys<Block> for Runtime {
777		fn decode_session_keys(
778			encoded: Vec<u8>,
779		) -> Option<Vec<(Vec<u8>, sp_core::crypto::KeyTypeId)>> {
780			SessionKeys::decode_into_raw_public_keys(&encoded)
781		}
782
783		fn generate_session_keys(seed: Option<Vec<u8>>) -> Vec<u8> {
784			SessionKeys::generate(seed)
785		}
786	}
787
788	impl sp_consensus_aura::AuraApi<Block, AuraId> for Runtime {
789		fn slot_duration() -> sp_consensus_aura::SlotDuration {
790			sp_consensus_aura::SlotDuration::from_millis(Aura::slot_duration())
791		}
792
793		fn authorities() -> Vec<AuraId> {
794			pallet_aura::Authorities::<Runtime>::get().into_inner()
795		}
796	}
797
798	impl frame_system_rpc_runtime_api::AccountNonceApi<Block, AccountId, Nonce> for Runtime {
799		fn account_nonce(account: AccountId) -> Nonce {
800			System::account_nonce(account)
801		}
802	}
803
804	impl pallet_transaction_payment_rpc_runtime_api::TransactionPaymentApi<Block, Balance> for Runtime {
805		fn query_info(
806			uxt: <Block as BlockT>::Extrinsic,
807			len: u32,
808		) -> pallet_transaction_payment_rpc_runtime_api::RuntimeDispatchInfo<Balance> {
809			TransactionPayment::query_info(uxt, len)
810		}
811		fn query_fee_details(
812			uxt: <Block as BlockT>::Extrinsic,
813			len: u32,
814		) -> pallet_transaction_payment::FeeDetails<Balance> {
815			TransactionPayment::query_fee_details(uxt, len)
816		}
817		fn query_weight_to_fee(weight: Weight) -> Balance {
818			TransactionPayment::weight_to_fee(weight)
819		}
820		fn query_length_to_fee(length: u32) -> Balance {
821			TransactionPayment::length_to_fee(length)
822		}
823	}
824
825	impl pallet_transaction_payment_rpc_runtime_api::TransactionPaymentCallApi<Block, Balance, RuntimeCall>
826		for Runtime
827	{
828		fn query_call_info(
829			call: RuntimeCall,
830			len: u32,
831		) -> pallet_transaction_payment::RuntimeDispatchInfo<Balance> {
832			TransactionPayment::query_call_info(call, len)
833		}
834		fn query_call_fee_details(
835			call: RuntimeCall,
836			len: u32,
837		) -> pallet_transaction_payment::FeeDetails<Balance> {
838			TransactionPayment::query_call_fee_details(call, len)
839		}
840		fn query_weight_to_fee(weight: Weight) -> Balance {
841			TransactionPayment::weight_to_fee(weight)
842		}
843		fn query_length_to_fee(length: u32) -> Balance {
844			TransactionPayment::length_to_fee(length)
845		}
846	}
847
848	impl cumulus_primitives_core::CollectCollationInfo<Block> for Runtime {
849		fn collect_collation_info(header: &<Block as BlockT>::Header) -> cumulus_primitives_core::CollationInfo {
850			ParachainSystem::collect_collation_info(header)
851		}
852	}
853
854	impl sp_genesis_builder::GenesisBuilder<Block> for Runtime {
855		fn build_state(config: Vec<u8>) -> sp_genesis_builder::Result {
856			build_state::<RuntimeGenesisConfig>(config)
857		}
858
859		fn get_preset(id: &Option<sp_genesis_builder::PresetId>) -> Option<Vec<u8>> {
860			get_preset::<RuntimeGenesisConfig>(id, &genesis_config_presets::get_preset)
861		}
862
863		fn preset_names() -> Vec<sp_genesis_builder::PresetId> {
864			genesis_config_presets::preset_names()
865		}
866	}
867
868	impl cumulus_primitives_core::RelayParentOffsetApi<Block> for Runtime {
869		fn relay_parent_offset() -> u32 {
870			0
871		}
872	}
873
874	impl cumulus_primitives_aura::AuraUnincludedSegmentApi<Block> for Runtime {
875		fn can_build_upon(
876			included_hash: <Block as BlockT>::Hash,
877			slot: cumulus_primitives_aura::Slot,
878		) -> bool {
879			ConsensusHook::can_build_upon(included_hash, slot)
880		}
881	}
882
883	impl cumulus_primitives_core::GetParachainInfo<Block> for Runtime {
884		fn parachain_id() -> ParaId {
885			ParachainInfo::parachain_id()
886		}
887	}
888}
889
890cumulus_pallet_parachain_system::register_validate_block! {
891	Runtime = Runtime,
892	BlockExecutor = cumulus_pallet_aura_ext::BlockExecutor::<Runtime, Executive>,
893}