pallet_message_queue/
lib.rs

1// This file is part of Substrate.
2
3// Copyright (C) Parity Technologies (UK) Ltd.
4// SPDX-License-Identifier: Apache-2.0
5
6// Licensed under the Apache License, Version 2.0 (the "License");
7// you may not use this file except in compliance with the License.
8// You may obtain a copy of the License at
9//
10// 	http://www.apache.org/licenses/LICENSE-2.0
11//
12// Unless required by applicable law or agreed to in writing, software
13// distributed under the License is distributed on an "AS IS" BASIS,
14// WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
15// See the License for the specific language governing permissions and
16// limitations under the License.
17
18//! # Generalized Message Queue Pallet
19//!
20//! Provides generalized message queuing and processing capabilities on a per-queue basis for
21//! arbitrary use-cases.
22//!
23//! # Design Goals
24//!
25//! 1. Minimal assumptions about `Message`s and `MessageOrigin`s. Both should be MEL bounded blobs.
26//!  This ensures the generality and reusability of the pallet.
27//! 2. Well known and tightly limited pre-dispatch PoV weights, especially for message execution.
28//!  This is paramount for the success of the pallet since message execution is done in
29//!  `on_initialize` which must _never_ under-estimate its PoV weight. It also needs a frugal PoV
30//!  footprint since PoV is scarce and this is (possibly) done in every block. This must also hold
31//! in  the presence of unpredictable message size distributions.
32//! 3. Usable as XCMP, DMP and UMP message/dispatch queue - possibly through adapter types.
33//!
34//! # Design
35//!
36//! The pallet has means to enqueue, store and process messages. This is implemented by having
37//! *queues* which store enqueued messages and can be *served* to process said messages. A queue is
38//! identified by its origin in the `BookStateFor`. Each message has an origin which defines into
39//! which queue it will be stored. Messages are stored by being appended to the last [`Page`] of a
40//! book. Each book keeps track of its pages by indexing `Pages`. The `ReadyRing` contains all
41//! queues which hold at least one unprocessed message and are thereby *ready* to be serviced. The
42//! `ServiceHead` indicates which *ready* queue is the next to be serviced.
43//! The pallet implements [`frame_support::traits::EnqueueMessage`],
44//! [`frame_support::traits::ServiceQueues`] and has [`frame_support::traits::ProcessMessage`] and
45//! [`OnQueueChanged`] hooks to communicate with the outside world.
46//!
47//! NOTE: The storage items are not linked since they are not public.
48//!
49//! **Message Execution**
50//!
51//! Executing a message is offloaded to the [`Config::MessageProcessor`] which contains the actual
52//! logic of how to handle the message since they are blobs. Storage changes are not rolled back on
53//! error.
54//!
55//! A failed message can be temporarily or permanently overweight. The pallet will perpetually try
56//! to execute a temporarily overweight message. A permanently overweight message is skipped and
57//! must be executed manually.
58//!
59//! **Reentrancy**
60//!
61//! This pallet has two entry points for executing (possibly recursive) logic;
62//! [`Pallet::service_queues`] and [`Pallet::execute_overweight`]. Both entry points are guarded by
63//! the same mutex to error on reentrancy. The only functions that are explicitly **allowed** to be
64//! called by a message processor are: [`Pallet::enqueue_message`] and
65//! [`Pallet::enqueue_messages`]. All other functions are forbidden and error with
66//! [`Error::RecursiveDisallowed`].
67//!
68//! **Pagination**
69//!
70//! Queues are stored in a *paged* manner by splitting their messages into [`Page`]s. This results
71//! in a lot of complexity when implementing the pallet but is completely necessary to achieve the
72//! second #[Design Goal](design-goals). The problem comes from the fact a message can *possibly* be
73//! quite large, lets say 64KiB. This then results in a *MEL* of at least 64KiB which results in a
74//! PoV of at least 64KiB. Now we have the assumption that most messages are much shorter than their
75//! maximum allowed length. This would result in most messages having a pre-dispatch PoV size which
76//! is much larger than their post-dispatch PoV size, possibly by a factor of thousand. Disregarding
77//! this observation would cripple the processing power of the pallet since it cannot straighten out
78//! this discrepancy at runtime. Conceptually, the implementation is packing as many messages into a
79//! single bounded vec, as actually fit into the bounds. This reduces the wasted PoV.
80//!
81//! **Page Data Layout**
82//!
83//! A Page contains a heap which holds all its messages. The heap is built by concatenating
84//! `(ItemHeader, Message)` pairs. The [`ItemHeader`] contains the length of the message which is
85//! needed for retrieving it. This layout allows for constant access time of the next message and
86//! linear access time for any message in the page. The header must remain minimal to reduce its PoV
87//! impact.
88//!
89//! **Weight Metering**
90//!
91//! The pallet utilizes the [`sp_weights::WeightMeter`] to manually track its consumption to always
92//! stay within the required limit. This implies that the message processor hook can calculate the
93//! weight of a message without executing it. This restricts the possible use-cases but is necessary
94//! since the pallet runs in `on_initialize` which has a hard weight limit. The weight meter is used
95//! in a way that `can_accrue` and `check_accrue` are always used to check the remaining weight of
96//! an operation before committing to it. The process of exiting due to insufficient weight is
97//! termed "bailing".
98//!
99//! # Scenario: Message enqueuing
100//!
101//! A message `m` is enqueued for origin `o` into queue `Q[o]` through
102//! [`frame_support::traits::EnqueueMessage::enqueue_message`]`(m, o)`.
103//!
104//! First the queue is either loaded if it exists or otherwise created with empty default values.
105//! The message is then inserted to the queue by appended it into its last `Page` or by creating a
106//! new `Page` just for `m` if it does not fit in there. The number of messages in the `Book` is
107//! incremented.
108//!
109//! `Q[o]` is now *ready* which will eventually result in `m` being processed.
110//!
111//! # Scenario: Message processing
112//!
113//! The pallet runs each block in `on_initialize` or when being manually called through
114//! [`frame_support::traits::ServiceQueues::service_queues`].
115//!
116//! First it tries to "rotate" the `ReadyRing` by one through advancing the `ServiceHead` to the
117//! next *ready* queue. It then starts to service this queue by servicing as many pages of it as
118//! possible. Servicing a page means to execute as many message of it as possible. Each executed
119//! message is marked as *processed* if the [`Config::MessageProcessor`] return Ok. An event
120//! [`Event::Processed`] is emitted afterwards. It is possible that the weight limit of the pallet
121//! will never allow a specific message to be executed. In this case it remains as unprocessed and
122//! is skipped. This process stops if either there are no more messages in the queue or the
123//! remaining weight became insufficient to service this queue. If there is enough weight it tries
124//! to advance to the next *ready* queue and service it. This continues until there are no more
125//! queues on which it can make progress or not enough weight to check that.
126//!
127//! # Scenario: Overweight execution
128//!
129//! A permanently over-weight message which was skipped by the message processing will never be
130//! executed automatically through `on_initialize` nor by calling
131//! [`frame_support::traits::ServiceQueues::service_queues`].
132//!
133//! Manual intervention in the form of
134//! [`frame_support::traits::ServiceQueues::execute_overweight`] is necessary. Overweight messages
135//! emit an [`Event::OverweightEnqueued`] event which can be used to extract the arguments for
136//! manual execution. This only works on permanently overweight messages. There is no guarantee that
137//! this will work since the message could be part of a stale page and be reaped before execution
138//! commences.
139//!
140//! # Terminology
141//!
142//! - `Message`: A blob of data into which the pallet has no introspection, defined as
143//! [`BoundedSlice<u8, MaxMessageLenOf<T>>`]. The message length is limited by [`MaxMessageLenOf`]
144//! which is calculated from [`Config::HeapSize`] and [`ItemHeader::max_encoded_len()`].
145//! - `MessageOrigin`: A generic *origin* of a message, defined as [`MessageOriginOf`]. The
146//! requirements for it are kept minimal to remain as generic as possible. The type is defined in
147//! [`frame_support::traits::ProcessMessage::Origin`].
148//! - `Page`: An array of `Message`s, see [`Page`]. Can never be empty.
149//! - `Book`: A list of `Page`s, see [`BookState`]. Can be empty.
150//! - `Queue`: A `Book` together with an `MessageOrigin` which can be part of the `ReadyRing`. Can
151//!   be empty.
152//! - `ReadyRing`: A double-linked list which contains all *ready* `Queue`s. It chains together the
153//!   queues via their `ready_neighbours` fields. A `Queue` is *ready* if it contains at least one
154//!   `Message` which can be processed. Can be empty.
155//! - `ServiceHead`: A pointer into the `ReadyRing` to the next `Queue` to be serviced.
156//! - (`un`)`processed`: A message is marked as *processed* after it was executed by the pallet. A
157//!   message which was either: not yet executed or could not be executed remains as `unprocessed`
158//!   which is the default state for a message after being enqueued.
159//! - `knitting`/`unknitting`: The means of adding or removing a `Queue` from the `ReadyRing`.
160//! - `MEL`: The Max Encoded Length of a type, see [`codec::MaxEncodedLen`].
161//! - `Reentrance`: To enter an execution context again before it has completed.
162//!
163//! # Properties
164//!
165//! **Liveness - Enqueueing**
166//!
167//! It is always possible to enqueue any message for any `MessageOrigin`.
168//!
169//! **Liveness - Processing**
170//!
171//! `on_initialize` always respects its finite weight-limit.
172//!
173//! **Progress - Enqueueing**
174//!
175//! An enqueued message immediately becomes *unprocessed* and thereby eligible for execution.
176//!
177//! **Progress - Processing**
178//!
179//! The pallet will execute at least one unprocessed message per block, if there is any. Ensuring
180//! this property needs careful consideration of the concrete weights, since it is possible that the
181//! weight limit of `on_initialize` never allows for the execution of even one message; trivially if
182//! the limit is set to zero. `integrity_test` can be used to ensure that this property holds.
183//!
184//! **Fairness - Enqueuing**
185//!
186//! Enqueueing a message for a specific `MessageOrigin` does not influence the ability to enqueue a
187//! message for the same of any other `MessageOrigin`; guaranteed by **Liveness - Enqueueing**.
188//!
189//! **Fairness - Processing**
190//!
191//! The average amount of weight available for message processing is the same for each queue if the
192//! number of queues is constant. Creating a new queue must therefore be, possibly economically,
193//! expensive. Currently this is archived by having one queue per para-chain/thread, which keeps the
194//! number of queues within `O(n)` and should be "good enough".
195
196#![deny(missing_docs)]
197#![cfg_attr(not(feature = "std"), no_std)]
198
199mod benchmarking;
200mod integration_test;
201mod mock;
202pub mod mock_helpers;
203mod tests;
204pub mod weights;
205
206extern crate alloc;
207
208use alloc::{vec, vec::Vec};
209use codec::{Codec, Decode, DecodeWithMemTracking, Encode, MaxEncodedLen};
210use core::{fmt::Debug, ops::Deref};
211use frame_support::{
212	defensive,
213	pallet_prelude::*,
214	traits::{
215		Defensive, DefensiveSaturating, DefensiveTruncateFrom, EnqueueMessage,
216		ExecuteOverweightError, Footprint, ProcessMessage, ProcessMessageError, QueueFootprint,
217		QueuePausedQuery, ServiceQueues,
218	},
219	BoundedSlice, CloneNoBound, DefaultNoBound,
220};
221use frame_system::pallet_prelude::*;
222pub use pallet::*;
223use scale_info::TypeInfo;
224use sp_arithmetic::traits::{BaseArithmetic, Unsigned};
225use sp_core::{defer, H256};
226use sp_runtime::{
227	traits::{One, Zero},
228	SaturatedConversion, Saturating, TransactionOutcome,
229};
230use sp_weights::WeightMeter;
231pub use weights::WeightInfo;
232
233/// Type for identifying a page.
234type PageIndex = u32;
235
236/// Data encoded and prefixed to the encoded `MessageItem`.
237#[derive(Encode, Decode, PartialEq, MaxEncodedLen, Debug)]
238pub struct ItemHeader<Size> {
239	/// The length of this item, not including the size of this header. The next item of the page
240	/// follows immediately after the payload of this item.
241	payload_len: Size,
242	/// Whether this item has been processed.
243	is_processed: bool,
244}
245
246/// A page of messages. Pages always contain at least one item.
247#[derive(
248	CloneNoBound, Encode, Decode, RuntimeDebugNoBound, DefaultNoBound, TypeInfo, MaxEncodedLen,
249)]
250#[scale_info(skip_type_params(HeapSize))]
251#[codec(mel_bound(Size: MaxEncodedLen))]
252pub struct Page<Size: Into<u32> + Debug + Clone + Default, HeapSize: Get<Size>> {
253	/// Messages remaining to be processed; this includes overweight messages which have been
254	/// skipped.
255	remaining: Size,
256	/// The size of all remaining messages to be processed.
257	///
258	/// Includes overweight messages outside of the `first` to `last` window.
259	remaining_size: Size,
260	/// The number of items before the `first` item in this page.
261	first_index: Size,
262	/// The heap-offset of the header of the first message item in this page which is ready for
263	/// processing.
264	first: Size,
265	/// The heap-offset of the header of the last message item in this page.
266	last: Size,
267	/// The heap. If `self.offset == self.heap.len()` then the page is empty and should be deleted.
268	heap: BoundedVec<u8, IntoU32<HeapSize, Size>>,
269}
270
271impl<
272		Size: BaseArithmetic + Unsigned + Copy + Into<u32> + Codec + MaxEncodedLen + Debug + Default,
273		HeapSize: Get<Size>,
274	> Page<Size, HeapSize>
275{
276	/// Create a [`Page`] from one unprocessed message.
277	fn from_message<T: Config>(message: BoundedSlice<u8, MaxMessageLenOf<T>>) -> Self {
278		let payload_len = message.len();
279		let data_len = ItemHeader::<Size>::max_encoded_len().saturating_add(payload_len);
280		let payload_len = payload_len.saturated_into();
281		let header = ItemHeader::<Size> { payload_len, is_processed: false };
282
283		let mut heap = Vec::with_capacity(data_len);
284		header.using_encoded(|h| heap.extend_from_slice(h));
285		heap.extend_from_slice(message.deref());
286
287		Page {
288			remaining: One::one(),
289			remaining_size: payload_len,
290			first_index: Zero::zero(),
291			first: Zero::zero(),
292			last: Zero::zero(),
293			heap: BoundedVec::defensive_truncate_from(heap),
294		}
295	}
296
297	/// Try to append one message to a page.
298	fn try_append_message<T: Config>(
299		&mut self,
300		message: BoundedSlice<u8, MaxMessageLenOf<T>>,
301	) -> Result<(), ()> {
302		let pos = self.heap.len();
303		let payload_len = message.len();
304		let data_len = ItemHeader::<Size>::max_encoded_len().saturating_add(payload_len);
305		let payload_len = payload_len.saturated_into();
306		let header = ItemHeader::<Size> { payload_len, is_processed: false };
307		let heap_size: u32 = HeapSize::get().into();
308		if (heap_size as usize).saturating_sub(self.heap.len()) < data_len {
309			// Can't fit.
310			return Err(())
311		}
312
313		let mut heap = core::mem::take(&mut self.heap).into_inner();
314		header.using_encoded(|h| heap.extend_from_slice(h));
315		heap.extend_from_slice(message.deref());
316		self.heap = BoundedVec::defensive_truncate_from(heap);
317		self.last = pos.saturated_into();
318		self.remaining.saturating_inc();
319		self.remaining_size.saturating_accrue(payload_len);
320		Ok(())
321	}
322
323	/// Returns the first message in the page without removing it.
324	///
325	/// SAFETY: Does not panic even on corrupted storage.
326	fn peek_first(&self) -> Option<BoundedSlice<u8, IntoU32<HeapSize, Size>>> {
327		if self.first > self.last {
328			return None
329		}
330		let f = (self.first.into() as usize).min(self.heap.len());
331		let mut item_slice = &self.heap[f..];
332		if let Ok(h) = ItemHeader::<Size>::decode(&mut item_slice) {
333			let payload_len = h.payload_len.into() as usize;
334			if payload_len <= item_slice.len() {
335				// impossible to truncate since is sliced up from `self.heap: BoundedVec<u8,
336				// HeapSize>`
337				return Some(BoundedSlice::defensive_truncate_from(&item_slice[..payload_len]))
338			}
339		}
340		defensive!("message-queue: heap corruption");
341		None
342	}
343
344	/// Point `first` at the next message, marking the first as processed if `is_processed` is true.
345	fn skip_first(&mut self, is_processed: bool) {
346		let f = (self.first.into() as usize).min(self.heap.len());
347		if let Ok(mut h) = ItemHeader::decode(&mut &self.heap[f..]) {
348			if is_processed && !h.is_processed {
349				h.is_processed = true;
350				h.using_encoded(|d| self.heap[f..f + d.len()].copy_from_slice(d));
351				self.remaining.saturating_dec();
352				self.remaining_size.saturating_reduce(h.payload_len);
353			}
354			self.first
355				.saturating_accrue(ItemHeader::<Size>::max_encoded_len().saturated_into());
356			self.first.saturating_accrue(h.payload_len);
357			self.first_index.saturating_inc();
358		}
359	}
360
361	/// Return the message with index `index` in the form of `(position, processed, message)`.
362	fn peek_index(&self, index: usize) -> Option<(usize, bool, &[u8])> {
363		let mut pos = 0;
364		let mut item_slice = &self.heap[..];
365		let header_len: usize = ItemHeader::<Size>::max_encoded_len().saturated_into();
366		for _ in 0..index {
367			let h = ItemHeader::<Size>::decode(&mut item_slice).ok()?;
368			let item_len = h.payload_len.into() as usize;
369			if item_slice.len() < item_len {
370				return None
371			}
372			item_slice = &item_slice[item_len..];
373			pos.saturating_accrue(header_len.saturating_add(item_len));
374		}
375		let h = ItemHeader::<Size>::decode(&mut item_slice).ok()?;
376		if item_slice.len() < h.payload_len.into() as usize {
377			return None
378		}
379		item_slice = &item_slice[..h.payload_len.into() as usize];
380		Some((pos, h.is_processed, item_slice))
381	}
382
383	/// Set the `is_processed` flag for the item at `pos` to be `true` if not already and decrement
384	/// the `remaining` counter of the page.
385	///
386	/// Does nothing if no [`ItemHeader`] could be decoded at the given position.
387	fn note_processed_at_pos(&mut self, pos: usize) {
388		if let Ok(mut h) = ItemHeader::<Size>::decode(&mut &self.heap[pos..]) {
389			if !h.is_processed {
390				h.is_processed = true;
391				h.using_encoded(|d| self.heap[pos..pos + d.len()].copy_from_slice(d));
392				self.remaining.saturating_dec();
393				self.remaining_size.saturating_reduce(h.payload_len);
394			}
395		}
396	}
397
398	/// Returns whether the page is *complete* which means that no messages remain.
399	fn is_complete(&self) -> bool {
400		self.remaining.is_zero()
401	}
402}
403
404/// A single link in the double-linked Ready Ring list.
405#[derive(Clone, Encode, Decode, MaxEncodedLen, TypeInfo, RuntimeDebug, PartialEq)]
406pub struct Neighbours<MessageOrigin> {
407	/// The previous queue.
408	prev: MessageOrigin,
409	/// The next queue.
410	next: MessageOrigin,
411}
412
413/// The state of a queue as represented by a book of its pages.
414///
415/// Each queue has exactly one book which holds all of its pages. All pages of a book combined
416/// contain all of the messages of its queue; hence the name *Book*.
417/// Books can be chained together in a double-linked fashion through their `ready_neighbours` field.
418#[derive(Clone, Encode, Decode, MaxEncodedLen, TypeInfo, RuntimeDebug)]
419pub struct BookState<MessageOrigin> {
420	/// The first page with some items to be processed in it. If this is `>= end`, then there are
421	/// no pages with items to be processing in them.
422	begin: PageIndex,
423	/// One more than the last page with some items to be processed in it.
424	end: PageIndex,
425	/// The number of pages stored at present.
426	///
427	/// This might be larger than `end-begin`, because we keep pages with unprocessed overweight
428	/// messages outside of the end/begin window.
429	count: PageIndex,
430	/// If this book has any ready pages, then this will be `Some` with the previous and next
431	/// neighbours. This wraps around.
432	ready_neighbours: Option<Neighbours<MessageOrigin>>,
433	/// The number of unprocessed messages stored at present.
434	message_count: u64,
435	/// The total size of all unprocessed messages stored at present.
436	size: u64,
437}
438
439impl<MessageOrigin> Default for BookState<MessageOrigin> {
440	fn default() -> Self {
441		Self { begin: 0, end: 0, count: 0, ready_neighbours: None, message_count: 0, size: 0 }
442	}
443}
444
445impl<MessageOrigin> From<BookState<MessageOrigin>> for QueueFootprint {
446	fn from(book: BookState<MessageOrigin>) -> Self {
447		QueueFootprint {
448			pages: book.count,
449			ready_pages: book.end.defensive_saturating_sub(book.begin),
450			storage: Footprint { count: book.message_count, size: book.size },
451		}
452	}
453}
454
455/// Handler code for when the items in a queue change.
456pub trait OnQueueChanged<Id> {
457	/// Note that the queue `id` now has `item_count` items in it, taking up `items_size` bytes.
458	fn on_queue_changed(id: Id, fp: QueueFootprint);
459}
460
461impl<Id> OnQueueChanged<Id> for () {
462	fn on_queue_changed(_: Id, _: QueueFootprint) {}
463}
464
465/// Allows to force the processing head to a specific queue.
466pub trait ForceSetHead<O> {
467	/// Set the `ServiceHead` to `origin`.
468	///
469	/// This function:
470	/// - `Err`: Queue did not exist, not enough weight or other error.
471	/// - `Ok(true)`: The service head was updated.
472	/// - `Ok(false)`: The service head was not updated since the queue is empty.
473	fn force_set_head(weight: &mut WeightMeter, origin: &O) -> Result<bool, ()>;
474}
475
476#[frame_support::pallet]
477pub mod pallet {
478	use super::*;
479
480	#[pallet::pallet]
481	pub struct Pallet<T>(_);
482
483	/// The module configuration trait.
484	#[pallet::config]
485	pub trait Config: frame_system::Config {
486		/// The overarching event type.
487		type RuntimeEvent: From<Event<Self>> + IsType<<Self as frame_system::Config>::RuntimeEvent>;
488
489		/// Weight information for extrinsics in this pallet.
490		type WeightInfo: WeightInfo;
491
492		/// Processor for a message.
493		///
494		/// Storage changes are not rolled back on error.
495		///
496		/// # Benchmarking
497		///
498		/// Must be set to [`mock_helpers::NoopMessageProcessor`] for benchmarking.
499		/// Other message processors that consumes exactly (1, 1) weight for any give message will
500		/// work as well. Otherwise the benchmarking will also measure the weight of the message
501		/// processor, which is not desired.
502		type MessageProcessor: ProcessMessage;
503
504		/// Page/heap size type.
505		type Size: BaseArithmetic
506			+ Unsigned
507			+ Copy
508			+ Into<u32>
509			+ Member
510			+ Encode
511			+ Decode
512			+ MaxEncodedLen
513			+ TypeInfo
514			+ Default;
515
516		/// Code to be called when a message queue changes - either with items introduced or
517		/// removed.
518		type QueueChangeHandler: OnQueueChanged<<Self::MessageProcessor as ProcessMessage>::Origin>;
519
520		/// Queried by the pallet to check whether a queue can be serviced.
521		///
522		/// This also applies to manual servicing via `execute_overweight` and `service_queues`. The
523		/// value of this is only polled once before servicing the queue. This means that changes to
524		/// it that happen *within* the servicing will not be reflected.
525		type QueuePausedQuery: QueuePausedQuery<<Self::MessageProcessor as ProcessMessage>::Origin>;
526
527		/// The size of the page; this implies the maximum message size which can be sent.
528		///
529		/// A good value depends on the expected message sizes, their weights, the weight that is
530		/// available for processing them and the maximal needed message size. The maximal message
531		/// size is slightly lower than this as defined by [`MaxMessageLenOf`].
532		#[pallet::constant]
533		type HeapSize: Get<Self::Size>;
534
535		/// The maximum number of stale pages (i.e. of overweight messages) allowed before culling
536		/// can happen. Once there are more stale pages than this, then historical pages may be
537		/// dropped, even if they contain unprocessed overweight messages.
538		#[pallet::constant]
539		type MaxStale: Get<u32>;
540
541		/// The amount of weight (if any) which should be provided to the message queue for
542		/// servicing enqueued items `on_initialize`.
543		///
544		/// This may be legitimately `None` in the case that you will call
545		/// `ServiceQueues::service_queues` manually or set [`Self::IdleMaxServiceWeight`] to have
546		/// it run in `on_idle`.
547		#[pallet::constant]
548		type ServiceWeight: Get<Option<Weight>>;
549
550		/// The maximum amount of weight (if any) to be used from remaining weight `on_idle` which
551		/// should be provided to the message queue for servicing enqueued items `on_idle`.
552		/// Useful for parachains to process messages at the same block they are received.
553		///
554		/// If `None`, it will not call `ServiceQueues::service_queues` in `on_idle`.
555		#[pallet::constant]
556		type IdleMaxServiceWeight: Get<Option<Weight>>;
557	}
558
559	#[pallet::event]
560	#[pallet::generate_deposit(pub(super) fn deposit_event)]
561	pub enum Event<T: Config> {
562		/// Message discarded due to an error in the `MessageProcessor` (usually a format error).
563		ProcessingFailed {
564			/// The `blake2_256` hash of the message.
565			id: H256,
566			/// The queue of the message.
567			origin: MessageOriginOf<T>,
568			/// The error that occurred.
569			///
570			/// This error is pretty opaque. More fine-grained errors need to be emitted as events
571			/// by the `MessageProcessor`.
572			error: ProcessMessageError,
573		},
574		/// Message is processed.
575		Processed {
576			/// The `blake2_256` hash of the message.
577			id: H256,
578			/// The queue of the message.
579			origin: MessageOriginOf<T>,
580			/// How much weight was used to process the message.
581			weight_used: Weight,
582			/// Whether the message was processed.
583			///
584			/// Note that this does not mean that the underlying `MessageProcessor` was internally
585			/// successful. It *solely* means that the MQ pallet will treat this as a success
586			/// condition and discard the message. Any internal error needs to be emitted as events
587			/// by the `MessageProcessor`.
588			success: bool,
589		},
590		/// Message placed in overweight queue.
591		OverweightEnqueued {
592			/// The `blake2_256` hash of the message.
593			id: [u8; 32],
594			/// The queue of the message.
595			origin: MessageOriginOf<T>,
596			/// The page of the message.
597			page_index: PageIndex,
598			/// The index of the message within the page.
599			message_index: T::Size,
600		},
601		/// This page was reaped.
602		PageReaped {
603			/// The queue of the page.
604			origin: MessageOriginOf<T>,
605			/// The index of the page.
606			index: PageIndex,
607		},
608	}
609
610	#[pallet::error]
611	pub enum Error<T> {
612		/// Page is not reapable because it has items remaining to be processed and is not old
613		/// enough.
614		NotReapable,
615		/// Page to be reaped does not exist.
616		NoPage,
617		/// The referenced message could not be found.
618		NoMessage,
619		/// The message was already processed and cannot be processed again.
620		AlreadyProcessed,
621		/// The message is queued for future execution.
622		Queued,
623		/// There is temporarily not enough weight to continue servicing messages.
624		InsufficientWeight,
625		/// This message is temporarily unprocessable.
626		///
627		/// Such errors are expected, but not guaranteed, to resolve themselves eventually through
628		/// retrying.
629		TemporarilyUnprocessable,
630		/// The queue is paused and no message can be executed from it.
631		///
632		/// This can change at any time and may resolve in the future by re-trying.
633		QueuePaused,
634		/// Another call is in progress and needs to finish before this call can happen.
635		RecursiveDisallowed,
636	}
637
638	/// The index of the first and last (non-empty) pages.
639	#[pallet::storage]
640	pub type BookStateFor<T: Config> =
641		StorageMap<_, Twox64Concat, MessageOriginOf<T>, BookState<MessageOriginOf<T>>, ValueQuery>;
642
643	/// The origin at which we should begin servicing.
644	#[pallet::storage]
645	pub type ServiceHead<T: Config> = StorageValue<_, MessageOriginOf<T>, OptionQuery>;
646
647	/// The map of page indices to pages.
648	#[pallet::storage]
649	pub type Pages<T: Config> = StorageDoubleMap<
650		_,
651		Twox64Concat,
652		MessageOriginOf<T>,
653		Twox64Concat,
654		PageIndex,
655		Page<T::Size, T::HeapSize>,
656		OptionQuery,
657	>;
658
659	#[pallet::hooks]
660	impl<T: Config> Hooks<BlockNumberFor<T>> for Pallet<T> {
661		fn on_initialize(_n: BlockNumberFor<T>) -> Weight {
662			if let Some(weight_limit) = T::ServiceWeight::get() {
663				Self::service_queues_impl(weight_limit, ServiceQueuesContext::OnInitialize)
664			} else {
665				Weight::zero()
666			}
667		}
668
669		fn on_idle(_n: BlockNumberFor<T>, remaining_weight: Weight) -> Weight {
670			if let Some(weight_limit) = T::IdleMaxServiceWeight::get() {
671				// Make use of the remaining weight to process enqueued messages.
672				Self::service_queues_impl(
673					weight_limit.min(remaining_weight),
674					ServiceQueuesContext::OnIdle,
675				)
676			} else {
677				Weight::zero()
678			}
679		}
680
681		#[cfg(feature = "try-runtime")]
682		fn try_state(_: BlockNumberFor<T>) -> Result<(), sp_runtime::TryRuntimeError> {
683			Self::do_try_state()
684		}
685
686		/// Check all compile-time assumptions about [`crate::Config`].
687		#[cfg(test)]
688		fn integrity_test() {
689			Self::do_integrity_test().expect("Pallet config is valid; qed")
690		}
691	}
692
693	#[pallet::call]
694	impl<T: Config> Pallet<T> {
695		/// Remove a page which has no more messages remaining to be processed or is stale.
696		#[pallet::call_index(0)]
697		#[pallet::weight(T::WeightInfo::reap_page())]
698		pub fn reap_page(
699			origin: OriginFor<T>,
700			message_origin: MessageOriginOf<T>,
701			page_index: PageIndex,
702		) -> DispatchResult {
703			let _ = ensure_signed(origin)?;
704			Self::do_reap_page(&message_origin, page_index)
705		}
706
707		/// Execute an overweight message.
708		///
709		/// Temporary processing errors will be propagated whereas permanent errors are treated
710		/// as success condition.
711		///
712		/// - `origin`: Must be `Signed`.
713		/// - `message_origin`: The origin from which the message to be executed arrived.
714		/// - `page`: The page in the queue in which the message to be executed is sitting.
715		/// - `index`: The index into the queue of the message to be executed.
716		/// - `weight_limit`: The maximum amount of weight allowed to be consumed in the execution
717		///   of the message.
718		///
719		/// Benchmark complexity considerations: O(index + weight_limit).
720		#[pallet::call_index(1)]
721		#[pallet::weight(
722			T::WeightInfo::execute_overweight_page_updated().max(
723			T::WeightInfo::execute_overweight_page_removed()).saturating_add(*weight_limit)
724		)]
725		pub fn execute_overweight(
726			origin: OriginFor<T>,
727			message_origin: MessageOriginOf<T>,
728			page: PageIndex,
729			index: T::Size,
730			weight_limit: Weight,
731		) -> DispatchResultWithPostInfo {
732			let _ = ensure_signed(origin)?;
733			let actual_weight =
734				Self::do_execute_overweight(message_origin, page, index, weight_limit)?;
735			Ok(Some(actual_weight).into())
736		}
737	}
738}
739
740/// The status of a page after trying to execute its next message.
741#[derive(PartialEq, Debug)]
742enum PageExecutionStatus {
743	/// The execution bailed because there was not enough weight remaining.
744	Bailed,
745	/// The page did not make any progress on its execution.
746	///
747	/// This is a transient condition and can be handled by retrying - exactly like [Bailed].
748	NoProgress,
749	/// No more messages could be loaded. This does _not_ imply `page.is_complete()`.
750	///
751	/// The reasons for this status are:
752	///  - The end of the page is reached but there could still be skipped messages.
753	///  - The storage is corrupted.
754	NoMore,
755}
756
757/// The status after trying to execute the next item of a [`Page`].
758#[derive(PartialEq, Debug)]
759enum ItemExecutionStatus {
760	/// The execution bailed because there was not enough weight remaining.
761	Bailed,
762	/// The item did not make any progress on its execution.
763	///
764	/// This is a transient condition and can be handled by retrying - exactly like [Bailed].
765	NoProgress,
766	/// The item was not found.
767	NoItem,
768	/// Whether the execution of an item resulted in it being processed.
769	///
770	/// One reason for `false` would be permanently overweight.
771	Executed(bool),
772}
773
774/// The status of an attempt to process a message.
775#[derive(PartialEq)]
776enum MessageExecutionStatus {
777	/// There is not enough weight remaining at present.
778	InsufficientWeight,
779	/// There will never be enough weight.
780	Overweight,
781	/// The message was processed successfully.
782	Processed,
783	/// The message was processed and resulted in a, possibly permanent, error.
784	Unprocessable { permanent: bool },
785	/// The stack depth limit was reached.
786	///
787	/// We cannot just return `Unprocessable` in this case, because the processability of the
788	/// message depends on how the function was called. This may be a permanent error if it was
789	/// called by a top-level function, or a transient error if it was already called in a nested
790	/// function.
791	StackLimitReached,
792}
793
794/// The context to pass to [`Pallet::service_queues_impl`] through on_idle and on_initialize hooks
795/// We don't want to throw the defensive message if called from on_idle hook
796#[derive(PartialEq)]
797enum ServiceQueuesContext {
798	/// Context of on_idle hook.
799	OnIdle,
800	/// Context of on_initialize hook.
801	OnInitialize,
802	/// Context `service_queues` trait function.
803	ServiceQueues,
804}
805
806impl<T: Config> Pallet<T> {
807	/// Knit `origin` into the ready ring right at the end.
808	///
809	/// Return the two ready ring neighbours of `origin`.
810	fn ready_ring_knit(origin: &MessageOriginOf<T>) -> Result<Neighbours<MessageOriginOf<T>>, ()> {
811		if let Some(head) = ServiceHead::<T>::get() {
812			let mut head_book_state = BookStateFor::<T>::get(&head);
813			let mut head_neighbours = head_book_state.ready_neighbours.take().ok_or(())?;
814			let tail = head_neighbours.prev;
815			head_neighbours.prev = origin.clone();
816			head_book_state.ready_neighbours = Some(head_neighbours);
817			BookStateFor::<T>::insert(&head, head_book_state);
818
819			let mut tail_book_state = BookStateFor::<T>::get(&tail);
820			let mut tail_neighbours = tail_book_state.ready_neighbours.take().ok_or(())?;
821			tail_neighbours.next = origin.clone();
822			tail_book_state.ready_neighbours = Some(tail_neighbours);
823			BookStateFor::<T>::insert(&tail, tail_book_state);
824
825			Ok(Neighbours { next: head, prev: tail })
826		} else {
827			ServiceHead::<T>::put(origin);
828			Ok(Neighbours { next: origin.clone(), prev: origin.clone() })
829		}
830	}
831
832	fn ready_ring_unknit(origin: &MessageOriginOf<T>, neighbours: Neighbours<MessageOriginOf<T>>) {
833		if origin == &neighbours.next {
834			debug_assert!(
835				origin == &neighbours.prev,
836				"unknitting from single item ring; outgoing must be only item"
837			);
838			// Service queue empty.
839			ServiceHead::<T>::kill();
840		} else {
841			BookStateFor::<T>::mutate(&neighbours.next, |book_state| {
842				if let Some(ref mut n) = book_state.ready_neighbours {
843					n.prev = neighbours.prev.clone()
844				}
845			});
846			BookStateFor::<T>::mutate(&neighbours.prev, |book_state| {
847				if let Some(ref mut n) = book_state.ready_neighbours {
848					n.next = neighbours.next.clone()
849				}
850			});
851			if let Some(head) = ServiceHead::<T>::get() {
852				if &head == origin {
853					ServiceHead::<T>::put(neighbours.next);
854				}
855			} else {
856				defensive!("`ServiceHead` must be some if there was a ready queue");
857			}
858		}
859	}
860
861	/// Tries to bump the current `ServiceHead` to the next ready queue.
862	///
863	/// Returns the current head if it got be bumped and `None` otherwise.
864	fn bump_service_head(weight: &mut WeightMeter) -> Option<MessageOriginOf<T>> {
865		if weight.try_consume(T::WeightInfo::bump_service_head()).is_err() {
866			return None
867		}
868
869		if let Some(head) = ServiceHead::<T>::get() {
870			let mut head_book_state = BookStateFor::<T>::get(&head);
871			if let Some(head_neighbours) = head_book_state.ready_neighbours.take() {
872				ServiceHead::<T>::put(&head_neighbours.next);
873				Some(head)
874			} else {
875				defensive!("The head must point to a queue in the ready ring");
876				None
877			}
878		} else {
879			None
880		}
881	}
882
883	fn set_service_head(weight: &mut WeightMeter, queue: &MessageOriginOf<T>) -> Result<bool, ()> {
884		if weight.try_consume(T::WeightInfo::set_service_head()).is_err() {
885			return Err(())
886		}
887
888		// Ensure that we never set the head to an un-ready queue.
889		if BookStateFor::<T>::get(queue).ready_neighbours.is_some() {
890			ServiceHead::<T>::put(queue);
891			Ok(true)
892		} else {
893			Ok(false)
894		}
895	}
896
897	/// The maximal weight that a single message ever can consume.
898	///
899	/// Any message using more than this will be marked as permanently overweight and not
900	/// automatically re-attempted. Returns `None` if the servicing of a message cannot begin.
901	/// `Some(0)` means that only messages with no weight may be served.
902	fn max_message_weight(limit: Weight) -> Option<Weight> {
903		let service_weight = T::ServiceWeight::get().unwrap_or_default();
904		let on_idle_weight = T::IdleMaxServiceWeight::get().unwrap_or_default();
905
906		// Whatever weight is set, the one with the biggest one is used as the maximum weight. If a
907		// message is tried in one context and fails, it will be retried in the other context later.
908		let max_message_weight =
909			if service_weight.any_gt(on_idle_weight) { service_weight } else { on_idle_weight };
910
911		if max_message_weight.is_zero() {
912			// If no service weight is set, we need to use the given limit as max message weight.
913			limit.checked_sub(&Self::single_msg_overhead())
914		} else {
915			max_message_weight.checked_sub(&Self::single_msg_overhead())
916		}
917	}
918
919	/// The overhead of servicing a single message.
920	fn single_msg_overhead() -> Weight {
921		T::WeightInfo::bump_service_head()
922			.saturating_add(T::WeightInfo::service_queue_base())
923			.saturating_add(
924				T::WeightInfo::service_page_base_completion()
925					.max(T::WeightInfo::service_page_base_no_completion()),
926			)
927			.saturating_add(T::WeightInfo::service_page_item())
928			.saturating_add(T::WeightInfo::ready_ring_unknit())
929	}
930
931	/// Checks invariants of the pallet config.
932	///
933	/// The results of this can only be relied upon if the config values are set to constants.
934	#[cfg(test)]
935	fn do_integrity_test() -> Result<(), String> {
936		ensure!(!MaxMessageLenOf::<T>::get().is_zero(), "HeapSize too low");
937
938		let max_block = T::BlockWeights::get().max_block;
939
940		if let Some(service) = T::ServiceWeight::get() {
941			if Self::max_message_weight(service).is_none() {
942				return Err(format!(
943					"ServiceWeight too low: {}. Must be at least {}",
944					service,
945					Self::single_msg_overhead(),
946				))
947			}
948
949			if service.any_gt(max_block) {
950				return Err(format!(
951					"ServiceWeight {service} is bigger than max block weight {max_block}"
952				))
953			}
954		}
955
956		if let Some(on_idle) = T::IdleMaxServiceWeight::get() {
957			if on_idle.any_gt(max_block) {
958				return Err(format!(
959					"IdleMaxServiceWeight {on_idle} is bigger than max block weight {max_block}"
960				))
961			}
962		}
963
964		if let (Some(service_weight), Some(on_idle)) =
965			(T::ServiceWeight::get(), T::IdleMaxServiceWeight::get())
966		{
967			if !(service_weight.all_gt(on_idle) ||
968				on_idle.all_gt(service_weight) ||
969				service_weight == on_idle)
970			{
971				return Err("One of `ServiceWeight` or `IdleMaxServiceWeight` needs to be `all_gt` or both need to be equal.".into())
972			}
973		}
974
975		Ok(())
976	}
977
978	fn do_enqueue_messages<'a>(
979		origin: &MessageOriginOf<T>,
980		messages: impl Iterator<Item = BoundedSlice<'a, u8, MaxMessageLenOf<T>>>,
981	) {
982		let mut book_state = BookStateFor::<T>::get(origin);
983
984		let mut maybe_page = None;
985		// Check if we already have a page in progress.
986		if book_state.end > book_state.begin {
987			debug_assert!(book_state.ready_neighbours.is_some(), "Must be in ready ring if ready");
988			maybe_page = Pages::<T>::get(origin, book_state.end - 1).or_else(|| {
989				defensive!("Corruption: referenced page doesn't exist.");
990				None
991			});
992		}
993
994		for message in messages {
995			// Try to append the message to the current page if possible.
996			if let Some(mut page) = maybe_page {
997				maybe_page = match page.try_append_message::<T>(message) {
998					Ok(_) => Some(page),
999					Err(_) => {
1000						// Not enough space on the current page.
1001						// Let's save it, since we'll move to a new one.
1002						Pages::<T>::insert(origin, book_state.end - 1, page);
1003						None
1004					},
1005				}
1006			}
1007			// If not, add it to a new page.
1008			if maybe_page.is_none() {
1009				book_state.end.saturating_inc();
1010				book_state.count.saturating_inc();
1011				maybe_page = Some(Page::from_message::<T>(message));
1012			}
1013
1014			// Account for the message that we just added.
1015			book_state.message_count.saturating_inc();
1016			book_state
1017				.size
1018				// This should be payload size, but here the payload *is* the message.
1019				.saturating_accrue(message.len() as u64);
1020		}
1021
1022		// Save the last page that we created.
1023		if let Some(page) = maybe_page {
1024			Pages::<T>::insert(origin, book_state.end - 1, page);
1025		}
1026
1027		// Insert book state for current origin into the ready queue.
1028		if book_state.ready_neighbours.is_none() {
1029			match Self::ready_ring_knit(origin) {
1030				Ok(neighbours) => book_state.ready_neighbours = Some(neighbours),
1031				Err(()) => {
1032					defensive!("Ring state invalid when knitting");
1033				},
1034			}
1035		}
1036
1037		// NOTE: `T::QueueChangeHandler` is called by the caller.
1038		BookStateFor::<T>::insert(origin, book_state);
1039	}
1040
1041	/// Try to execute a single message that was marked as overweight.
1042	///
1043	/// The `weight_limit` is the weight that can be consumed to execute the message. The base
1044	/// weight of the function it self must be measured by the caller.
1045	pub fn do_execute_overweight(
1046		origin: MessageOriginOf<T>,
1047		page_index: PageIndex,
1048		index: T::Size,
1049		weight_limit: Weight,
1050	) -> Result<Weight, Error<T>> {
1051		match with_service_mutex(|| {
1052			Self::do_execute_overweight_inner(origin, page_index, index, weight_limit)
1053		}) {
1054			Err(()) => Err(Error::<T>::RecursiveDisallowed),
1055			Ok(x) => x,
1056		}
1057	}
1058
1059	/// Same as `do_execute_overweight` but must be called while holding the `service_mutex`.
1060	fn do_execute_overweight_inner(
1061		origin: MessageOriginOf<T>,
1062		page_index: PageIndex,
1063		index: T::Size,
1064		weight_limit: Weight,
1065	) -> Result<Weight, Error<T>> {
1066		let mut book_state = BookStateFor::<T>::get(&origin);
1067		ensure!(!T::QueuePausedQuery::is_paused(&origin), Error::<T>::QueuePaused);
1068
1069		let mut page = Pages::<T>::get(&origin, page_index).ok_or(Error::<T>::NoPage)?;
1070		let (pos, is_processed, payload) =
1071			page.peek_index(index.into() as usize).ok_or(Error::<T>::NoMessage)?;
1072		let payload_len = payload.len() as u64;
1073		ensure!(
1074			page_index < book_state.begin ||
1075				(page_index == book_state.begin && pos < page.first.into() as usize),
1076			Error::<T>::Queued
1077		);
1078		ensure!(!is_processed, Error::<T>::AlreadyProcessed);
1079		use MessageExecutionStatus::*;
1080		let mut weight_counter = WeightMeter::with_limit(weight_limit);
1081		match Self::process_message_payload(
1082			origin.clone(),
1083			page_index,
1084			index,
1085			payload,
1086			&mut weight_counter,
1087			Weight::MAX,
1088			// ^^^ We never recognise it as permanently overweight, since that would result in an
1089			// additional overweight event being deposited.
1090		) {
1091			Overweight | InsufficientWeight => Err(Error::<T>::InsufficientWeight),
1092			StackLimitReached | Unprocessable { permanent: false } =>
1093				Err(Error::<T>::TemporarilyUnprocessable),
1094			Unprocessable { permanent: true } | Processed => {
1095				page.note_processed_at_pos(pos);
1096				book_state.message_count.saturating_dec();
1097				book_state.size.saturating_reduce(payload_len);
1098				let page_weight = if page.remaining.is_zero() {
1099					debug_assert!(
1100						page.remaining_size.is_zero(),
1101						"no messages remaining; no space taken; qed"
1102					);
1103					Pages::<T>::remove(&origin, page_index);
1104					debug_assert!(book_state.count >= 1, "page exists, so book must have pages");
1105					book_state.count.saturating_dec();
1106					T::WeightInfo::execute_overweight_page_removed()
1107				// no need to consider .first or ready ring since processing an overweight page
1108				// would not alter that state.
1109				} else {
1110					Pages::<T>::insert(&origin, page_index, page);
1111					T::WeightInfo::execute_overweight_page_updated()
1112				};
1113				BookStateFor::<T>::insert(&origin, &book_state);
1114				T::QueueChangeHandler::on_queue_changed(origin, book_state.into());
1115				Ok(weight_counter.consumed().saturating_add(page_weight))
1116			},
1117		}
1118	}
1119
1120	/// Remove a stale page or one which has no more messages remaining to be processed.
1121	fn do_reap_page(origin: &MessageOriginOf<T>, page_index: PageIndex) -> DispatchResult {
1122		match with_service_mutex(|| Self::do_reap_page_inner(origin, page_index)) {
1123			Err(()) => Err(Error::<T>::RecursiveDisallowed.into()),
1124			Ok(x) => x,
1125		}
1126	}
1127
1128	/// Same as `do_reap_page` but must be called while holding the `service_mutex`.
1129	fn do_reap_page_inner(origin: &MessageOriginOf<T>, page_index: PageIndex) -> DispatchResult {
1130		let mut book_state = BookStateFor::<T>::get(origin);
1131		// definitely not reapable if the page's index is no less than the `begin`ning of ready
1132		// pages.
1133		ensure!(page_index < book_state.begin, Error::<T>::NotReapable);
1134
1135		let page = Pages::<T>::get(origin, page_index).ok_or(Error::<T>::NoPage)?;
1136
1137		// definitely reapable if the page has no messages in it.
1138		let reapable = page.remaining.is_zero();
1139
1140		// also reapable if the page index has dropped below our watermark.
1141		let cullable = || {
1142			let total_pages = book_state.count;
1143			let ready_pages = book_state.end.saturating_sub(book_state.begin).min(total_pages);
1144
1145			// The number of stale pages - i.e. pages which contain unprocessed overweight messages.
1146			// We would prefer to keep these around but will restrict how far into history they can
1147			// extend if we notice that there's too many of them.
1148			//
1149			// We don't know *where* in history these pages are so we use a dynamic formula which
1150			// reduces the historical time horizon as the stale pages pile up and increases it as
1151			// they reduce.
1152			let stale_pages = total_pages - ready_pages;
1153
1154			// The maximum number of stale pages (i.e. of overweight messages) allowed before
1155			// culling can happen at all. Once there are more stale pages than this, then historical
1156			// pages may be dropped, even if they contain unprocessed overweight messages.
1157			let max_stale = T::MaxStale::get();
1158
1159			// The amount beyond the maximum which are being used. If it's not beyond the maximum
1160			// then we exit now since no culling is needed.
1161			let overflow = match stale_pages.checked_sub(max_stale + 1) {
1162				Some(x) => x + 1,
1163				None => return false,
1164			};
1165
1166			// The special formula which tells us how deep into index-history we will pages. As
1167			// the overflow is greater (and thus the need to drop items from storage is more urgent)
1168			// this is reduced, allowing a greater range of pages to be culled.
1169			// With a minimum `overflow` (`1`), this returns `max_stale ** 2`, indicating we only
1170			// cull beyond that number of indices deep into history.
1171			// At this overflow increases, our depth reduces down to a limit of `max_stale`. We
1172			// never want to reduce below this since this will certainly allow enough pages to be
1173			// culled in order to bring `overflow` back to zero.
1174			let backlog = (max_stale * max_stale / overflow).max(max_stale);
1175
1176			let watermark = book_state.begin.saturating_sub(backlog);
1177			page_index < watermark
1178		};
1179		ensure!(reapable || cullable(), Error::<T>::NotReapable);
1180
1181		Pages::<T>::remove(origin, page_index);
1182		debug_assert!(book_state.count > 0, "reaping a page implies there are pages");
1183		book_state.count.saturating_dec();
1184		book_state.message_count.saturating_reduce(page.remaining.into() as u64);
1185		book_state.size.saturating_reduce(page.remaining_size.into() as u64);
1186		BookStateFor::<T>::insert(origin, &book_state);
1187		T::QueueChangeHandler::on_queue_changed(origin.clone(), book_state.into());
1188		Self::deposit_event(Event::PageReaped { origin: origin.clone(), index: page_index });
1189
1190		Ok(())
1191	}
1192
1193	/// Execute any messages remaining to be processed in the queue of `origin`, using up to
1194	/// `weight_limit` to do so. Any messages which would take more than `overweight_limit` to
1195	/// execute are deemed overweight and ignored.
1196	fn service_queue(
1197		origin: MessageOriginOf<T>,
1198		weight: &mut WeightMeter,
1199		overweight_limit: Weight,
1200	) -> (bool, Option<MessageOriginOf<T>>) {
1201		use PageExecutionStatus::*;
1202		if weight
1203			.try_consume(
1204				T::WeightInfo::service_queue_base()
1205					.saturating_add(T::WeightInfo::ready_ring_unknit()),
1206			)
1207			.is_err()
1208		{
1209			return (false, None)
1210		}
1211
1212		let mut book_state = BookStateFor::<T>::get(&origin);
1213		let mut total_processed = 0;
1214		if T::QueuePausedQuery::is_paused(&origin) {
1215			let next_ready = book_state.ready_neighbours.as_ref().map(|x| x.next.clone());
1216			return (false, next_ready)
1217		}
1218
1219		while book_state.end > book_state.begin {
1220			let (processed, status) =
1221				Self::service_page(&origin, &mut book_state, weight, overweight_limit);
1222			total_processed.saturating_accrue(processed);
1223			match status {
1224				// Store the page progress and do not go to the next one.
1225				Bailed | NoProgress => break,
1226				// Go to the next page if this one is at the end.
1227				NoMore => (),
1228			};
1229			book_state.begin.saturating_inc();
1230		}
1231		let next_ready = book_state.ready_neighbours.as_ref().map(|x| x.next.clone());
1232		if book_state.begin >= book_state.end {
1233			// No longer ready - unknit.
1234			if let Some(neighbours) = book_state.ready_neighbours.take() {
1235				Self::ready_ring_unknit(&origin, neighbours);
1236			} else if total_processed > 0 {
1237				defensive!("Freshly processed queue must have been ready");
1238			}
1239		}
1240		BookStateFor::<T>::insert(&origin, &book_state);
1241		if total_processed > 0 {
1242			T::QueueChangeHandler::on_queue_changed(origin, book_state.into());
1243		}
1244		(total_processed > 0, next_ready)
1245	}
1246
1247	/// Service as many messages of a page as possible.
1248	///
1249	/// Returns how many messages were processed and the page's status.
1250	fn service_page(
1251		origin: &MessageOriginOf<T>,
1252		book_state: &mut BookStateOf<T>,
1253		weight: &mut WeightMeter,
1254		overweight_limit: Weight,
1255	) -> (u32, PageExecutionStatus) {
1256		use PageExecutionStatus::*;
1257		if weight
1258			.try_consume(
1259				T::WeightInfo::service_page_base_completion()
1260					.max(T::WeightInfo::service_page_base_no_completion()),
1261			)
1262			.is_err()
1263		{
1264			return (0, Bailed)
1265		}
1266
1267		let page_index = book_state.begin;
1268		let mut page = match Pages::<T>::get(origin, page_index) {
1269			Some(p) => p,
1270			None => {
1271				defensive!("message-queue: referenced page not found");
1272				return (0, NoMore)
1273			},
1274		};
1275
1276		let mut total_processed = 0;
1277
1278		// Execute as many messages as possible.
1279		let status = loop {
1280			use ItemExecutionStatus::*;
1281			match Self::service_page_item(
1282				origin,
1283				page_index,
1284				book_state,
1285				&mut page,
1286				weight,
1287				overweight_limit,
1288			) {
1289				Bailed => break PageExecutionStatus::Bailed,
1290				NoItem => break PageExecutionStatus::NoMore,
1291				NoProgress => break PageExecutionStatus::NoProgress,
1292				// Keep going as long as we make progress...
1293				Executed(true) => total_processed.saturating_inc(),
1294				Executed(false) => (),
1295			}
1296		};
1297
1298		if page.is_complete() {
1299			debug_assert!(status != Bailed, "we never bail if a page became complete");
1300			Pages::<T>::remove(origin, page_index);
1301			debug_assert!(book_state.count > 0, "completing a page implies there are pages");
1302			book_state.count.saturating_dec();
1303		} else {
1304			Pages::<T>::insert(origin, page_index, page);
1305		}
1306		(total_processed, status)
1307	}
1308
1309	/// Execute the next message of a page.
1310	pub(crate) fn service_page_item(
1311		origin: &MessageOriginOf<T>,
1312		page_index: PageIndex,
1313		book_state: &mut BookStateOf<T>,
1314		page: &mut PageOf<T>,
1315		weight: &mut WeightMeter,
1316		overweight_limit: Weight,
1317	) -> ItemExecutionStatus {
1318		use MessageExecutionStatus::*;
1319		// This ugly pre-checking is needed for the invariant
1320		// "we never bail if a page became complete".
1321		if page.is_complete() {
1322			return ItemExecutionStatus::NoItem
1323		}
1324		if weight.try_consume(T::WeightInfo::service_page_item()).is_err() {
1325			return ItemExecutionStatus::Bailed
1326		}
1327
1328		let payload = &match page.peek_first() {
1329			Some(m) => m,
1330			None => return ItemExecutionStatus::NoItem,
1331		}[..];
1332		let payload_len = payload.len() as u64;
1333
1334		// Store these for the case that `process_message_payload` is recursive.
1335		Pages::<T>::insert(origin, page_index, &*page);
1336		BookStateFor::<T>::insert(origin, &*book_state);
1337
1338		let res = Self::process_message_payload(
1339			origin.clone(),
1340			page_index,
1341			page.first_index,
1342			payload,
1343			weight,
1344			overweight_limit,
1345		);
1346
1347		// And restore them afterwards to see the changes of a recursive call.
1348		*book_state = BookStateFor::<T>::get(origin);
1349		if let Some(new_page) = Pages::<T>::get(origin, page_index) {
1350			*page = new_page;
1351		} else {
1352			defensive!("page must exist since we just inserted it and recursive calls are not allowed to remove anything");
1353			return ItemExecutionStatus::NoItem
1354		};
1355
1356		let is_processed = match res {
1357			InsufficientWeight => return ItemExecutionStatus::Bailed,
1358			Unprocessable { permanent: false } => return ItemExecutionStatus::NoProgress,
1359			Processed | Unprocessable { permanent: true } | StackLimitReached => true,
1360			Overweight => false,
1361		};
1362
1363		if is_processed {
1364			book_state.message_count.saturating_dec();
1365			book_state.size.saturating_reduce(payload_len as u64);
1366		}
1367		page.skip_first(is_processed);
1368		ItemExecutionStatus::Executed(is_processed)
1369	}
1370
1371	/// Ensure the correctness of state of this pallet.
1372	///
1373	/// # Assumptions-
1374	///
1375	/// If `serviceHead` points to a ready Queue, then BookState of that Queue has:
1376	///
1377	/// * `message_count` > 0
1378	/// * `size` > 0
1379	/// * `end` > `begin`
1380	/// * Some(ready_neighbours)
1381	/// * If `ready_neighbours.next` == self.origin, then `ready_neighbours.prev` == self.origin
1382	///   (only queue in ring)
1383	///
1384	/// For Pages(begin to end-1) in BookState:
1385	///
1386	/// * `remaining` > 0
1387	/// * `remaining_size` > 0
1388	/// * `first` <= `last`
1389	/// * Every page can be decoded into peek_* functions
1390	#[cfg(any(test, feature = "try-runtime", feature = "std"))]
1391	pub fn do_try_state() -> Result<(), sp_runtime::TryRuntimeError> {
1392		// Checking memory corruption for BookStateFor
1393		ensure!(
1394			BookStateFor::<T>::iter_keys().count() == BookStateFor::<T>::iter_values().count(),
1395			"Memory Corruption in BookStateFor"
1396		);
1397		// Checking memory corruption for Pages
1398		ensure!(
1399			Pages::<T>::iter_keys().count() == Pages::<T>::iter_values().count(),
1400			"Memory Corruption in Pages"
1401		);
1402
1403		// Basic checks for each book
1404		for book in BookStateFor::<T>::iter_values() {
1405			ensure!(book.end >= book.begin, "Invariant");
1406			ensure!(book.end < 1 << 30, "Likely overflow or corruption");
1407			ensure!(book.message_count < 1 << 30, "Likely overflow or corruption");
1408			ensure!(book.size < 1 << 30, "Likely overflow or corruption");
1409			ensure!(book.count < 1 << 30, "Likely overflow or corruption");
1410
1411			let fp: QueueFootprint = book.into();
1412			ensure!(fp.ready_pages <= fp.pages, "There cannot be more ready than total pages");
1413		}
1414
1415		//loop around this origin
1416		let Some(starting_origin) = ServiceHead::<T>::get() else { return Ok(()) };
1417
1418		while let Some(head) = Self::bump_service_head(&mut WeightMeter::new()) {
1419			ensure!(
1420				BookStateFor::<T>::contains_key(&head),
1421				"Service head must point to an existing book"
1422			);
1423
1424			let head_book_state = BookStateFor::<T>::get(&head);
1425			ensure!(
1426				head_book_state.message_count > 0,
1427				"There must be some messages if in ReadyRing"
1428			);
1429			ensure!(head_book_state.size > 0, "There must be some message size if in ReadyRing");
1430			ensure!(
1431				head_book_state.end > head_book_state.begin,
1432				"End > Begin if unprocessed messages exists"
1433			);
1434			ensure!(
1435				head_book_state.ready_neighbours.is_some(),
1436				"There must be neighbours if in ReadyRing"
1437			);
1438
1439			if head_book_state.ready_neighbours.as_ref().unwrap().next == head {
1440				ensure!(
1441					head_book_state.ready_neighbours.as_ref().unwrap().prev == head,
1442					"Can only happen if only queue in ReadyRing"
1443				);
1444			}
1445
1446			for page_index in head_book_state.begin..head_book_state.end {
1447				let page = Pages::<T>::get(&head, page_index).unwrap();
1448				let remaining_messages = page.remaining;
1449				let mut counted_remaining_messages: u32 = 0;
1450				ensure!(
1451					remaining_messages > 0.into(),
1452					"These must be some messages that have not been processed yet!"
1453				);
1454
1455				for i in 0..u32::MAX {
1456					if let Some((_, processed, _)) = page.peek_index(i as usize) {
1457						if !processed {
1458							counted_remaining_messages += 1;
1459						}
1460					} else {
1461						break
1462					}
1463				}
1464
1465				ensure!(
1466					remaining_messages.into() == counted_remaining_messages,
1467					"Memory Corruption"
1468				);
1469			}
1470
1471			if head_book_state.ready_neighbours.as_ref().unwrap().next == starting_origin {
1472				break
1473			}
1474		}
1475		Ok(())
1476	}
1477
1478	/// Print the pages in each queue and the messages in each page.
1479	///
1480	/// Processed messages are prefixed with a `*` and the current `begin`ning page with a `>`.
1481	///
1482	/// # Example output
1483	///
1484	/// ```text
1485	/// queue Here:
1486	///   page 0: []
1487	/// > page 1: []
1488	///   page 2: ["\0weight=4", "\0c", ]
1489	///   page 3: ["\0bigbig 1", ]
1490	///   page 4: ["\0bigbig 2", ]
1491	///   page 5: ["\0bigbig 3", ]
1492	/// ```
1493	#[cfg(feature = "std")]
1494	pub fn debug_info() -> String {
1495		let mut info = String::new();
1496		for (origin, book_state) in BookStateFor::<T>::iter() {
1497			let mut queue = format!("queue {:?}:\n", &origin);
1498			let mut pages = Pages::<T>::iter_prefix(&origin).collect::<Vec<_>>();
1499			pages.sort_by(|(a, _), (b, _)| a.cmp(b));
1500			for (page_index, mut page) in pages.into_iter() {
1501				let page_info = if book_state.begin == page_index { ">" } else { " " };
1502				let mut page_info = format!(
1503					"{} page {} ({:?} first, {:?} last, {:?} remain): [ ",
1504					page_info, page_index, page.first, page.last, page.remaining
1505				);
1506				for i in 0..u32::MAX {
1507					if let Some((_, processed, message)) =
1508						page.peek_index(i.try_into().expect("std-only code"))
1509					{
1510						let msg = String::from_utf8_lossy(message);
1511						if processed {
1512							page_info.push('*');
1513						}
1514						page_info.push_str(&format!("{:?}, ", msg));
1515						page.skip_first(true);
1516					} else {
1517						break
1518					}
1519				}
1520				page_info.push_str("]\n");
1521				queue.push_str(&page_info);
1522			}
1523			info.push_str(&queue);
1524		}
1525		info
1526	}
1527
1528	/// Process a single message.
1529	///
1530	/// The base weight of this function needs to be accounted for by the caller. `weight` is the
1531	/// remaining weight to process the message. `overweight_limit` is the maximum weight that a
1532	/// message can ever consume. Messages above this limit are marked as permanently overweight.
1533	/// This process is also transactional, any form of error that occurs in processing a message
1534	/// causes storage changes to be rolled back.
1535	fn process_message_payload(
1536		origin: MessageOriginOf<T>,
1537		page_index: PageIndex,
1538		message_index: T::Size,
1539		message: &[u8],
1540		meter: &mut WeightMeter,
1541		overweight_limit: Weight,
1542	) -> MessageExecutionStatus {
1543		let mut id = sp_io::hashing::blake2_256(message);
1544		use ProcessMessageError::*;
1545		let prev_consumed = meter.consumed();
1546
1547		let transaction =
1548			storage::with_transaction(|| -> TransactionOutcome<Result<_, DispatchError>> {
1549				let res =
1550					T::MessageProcessor::process_message(message, origin.clone(), meter, &mut id);
1551				match &res {
1552					Ok(_) => TransactionOutcome::Commit(Ok(res)),
1553					Err(_) => TransactionOutcome::Rollback(Ok(res)),
1554				}
1555			});
1556
1557		let transaction = match transaction {
1558			Ok(result) => result,
1559			_ => {
1560				defensive!(
1561					"Error occurred processing message, storage changes will be rolled back"
1562				);
1563				return MessageExecutionStatus::Unprocessable { permanent: true }
1564			},
1565		};
1566
1567		match transaction {
1568			Err(Overweight(w)) if w.any_gt(overweight_limit) => {
1569				// Permanently overweight.
1570				Self::deposit_event(Event::<T>::OverweightEnqueued {
1571					id,
1572					origin,
1573					page_index,
1574					message_index,
1575				});
1576				MessageExecutionStatus::Overweight
1577			},
1578			Err(Overweight(_)) => {
1579				// Temporarily overweight - save progress and stop processing this
1580				// queue.
1581				MessageExecutionStatus::InsufficientWeight
1582			},
1583			Err(Yield) => {
1584				// Processing should be reattempted later.
1585				MessageExecutionStatus::Unprocessable { permanent: false }
1586			},
1587			Err(error @ BadFormat | error @ Corrupt | error @ Unsupported) => {
1588				// Permanent error - drop
1589				Self::deposit_event(Event::<T>::ProcessingFailed { id: id.into(), origin, error });
1590				MessageExecutionStatus::Unprocessable { permanent: true }
1591			},
1592			Err(error @ StackLimitReached) => {
1593				Self::deposit_event(Event::<T>::ProcessingFailed { id: id.into(), origin, error });
1594				MessageExecutionStatus::StackLimitReached
1595			},
1596			Ok(success) => {
1597				// Success
1598				let weight_used = meter.consumed().saturating_sub(prev_consumed);
1599				Self::deposit_event(Event::<T>::Processed {
1600					id: id.into(),
1601					origin,
1602					weight_used,
1603					success,
1604				});
1605				MessageExecutionStatus::Processed
1606			},
1607		}
1608	}
1609
1610	fn service_queues_impl(weight_limit: Weight, context: ServiceQueuesContext) -> Weight {
1611		let mut weight = WeightMeter::with_limit(weight_limit);
1612
1613		// Get the maximum weight that processing a single message may take:
1614		let overweight_limit = Self::max_message_weight(weight_limit).unwrap_or_else(|| {
1615			if matches!(context, ServiceQueuesContext::OnInitialize) {
1616				defensive!("Not enough weight to service a single message.");
1617			}
1618			Weight::zero()
1619		});
1620
1621		match with_service_mutex(|| {
1622			let mut next = match Self::bump_service_head(&mut weight) {
1623				Some(h) => h,
1624				None => return weight.consumed(),
1625			};
1626			// The last queue that did not make any progress.
1627			// The loop aborts as soon as it arrives at this queue again without making any progress
1628			// on other queues in between.
1629			let mut last_no_progress = None;
1630
1631			loop {
1632				let (progressed, n) =
1633					Self::service_queue(next.clone(), &mut weight, overweight_limit);
1634				next = match n {
1635					Some(n) =>
1636						if !progressed {
1637							if last_no_progress == Some(n.clone()) {
1638								break
1639							}
1640							if last_no_progress.is_none() {
1641								last_no_progress = Some(next.clone())
1642							}
1643							n
1644						} else {
1645							last_no_progress = None;
1646							n
1647						},
1648					None => break,
1649				}
1650			}
1651			weight.consumed()
1652		}) {
1653			Err(()) => weight.consumed(),
1654			Ok(w) => w,
1655		}
1656	}
1657}
1658
1659impl<T: Config> ForceSetHead<MessageOriginOf<T>> for Pallet<T> {
1660	fn force_set_head(weight: &mut WeightMeter, origin: &MessageOriginOf<T>) -> Result<bool, ()> {
1661		Pallet::<T>::set_service_head(weight, origin)
1662	}
1663}
1664
1665/// Run a closure that errors on re-entrance. Meant to be used by anything that services queues.
1666pub(crate) fn with_service_mutex<F: FnOnce() -> R, R>(f: F) -> Result<R, ()> {
1667	// Holds the singleton token instance.
1668	environmental::environmental!(token: Option<()>);
1669
1670	token::using_once(&mut Some(()), || {
1671		// The first `ok_or` should always be `Ok` since we are inside a `using_once`.
1672		let hold = token::with(|t| t.take()).ok_or(()).defensive()?.ok_or(())?;
1673
1674		// Put the token back when we're done.
1675		defer! {
1676			token::with(|t| {
1677				*t = Some(hold);
1678			});
1679		}
1680
1681		Ok(f())
1682	})
1683}
1684
1685/// Provides a [`sp_core::Get`] to access the `MEL` of a [`codec::MaxEncodedLen`] type.
1686pub struct MaxEncodedLenOf<T>(core::marker::PhantomData<T>);
1687impl<T: MaxEncodedLen> Get<u32> for MaxEncodedLenOf<T> {
1688	fn get() -> u32 {
1689		T::max_encoded_len() as u32
1690	}
1691}
1692
1693/// Calculates the maximum message length and exposed it through the [`codec::MaxEncodedLen`] trait.
1694pub struct MaxMessageLen<Origin, Size, HeapSize>(
1695	core::marker::PhantomData<(Origin, Size, HeapSize)>,
1696);
1697impl<Origin: MaxEncodedLen, Size: MaxEncodedLen + Into<u32>, HeapSize: Get<Size>> Get<u32>
1698	for MaxMessageLen<Origin, Size, HeapSize>
1699{
1700	fn get() -> u32 {
1701		(HeapSize::get().into()).saturating_sub(ItemHeader::<Size>::max_encoded_len() as u32)
1702	}
1703}
1704
1705/// The maximal message length.
1706pub type MaxMessageLenOf<T> =
1707	MaxMessageLen<MessageOriginOf<T>, <T as Config>::Size, <T as Config>::HeapSize>;
1708/// The maximal encoded origin length.
1709pub type MaxOriginLenOf<T> = MaxEncodedLenOf<MessageOriginOf<T>>;
1710/// The `MessageOrigin` of this pallet.
1711pub type MessageOriginOf<T> = <<T as Config>::MessageProcessor as ProcessMessage>::Origin;
1712/// The maximal heap size of a page.
1713pub type HeapSizeU32Of<T> = IntoU32<<T as Config>::HeapSize, <T as Config>::Size>;
1714/// The [`Page`] of this pallet.
1715pub type PageOf<T> = Page<<T as Config>::Size, <T as Config>::HeapSize>;
1716/// The [`BookState`] of this pallet.
1717pub type BookStateOf<T> = BookState<MessageOriginOf<T>>;
1718
1719/// Converts a [`sp_core::Get`] with returns a type that can be cast into an `u32` into a `Get`
1720/// which returns an `u32`.
1721pub struct IntoU32<T, O>(core::marker::PhantomData<(T, O)>);
1722impl<T: Get<O>, O: Into<u32>> Get<u32> for IntoU32<T, O> {
1723	fn get() -> u32 {
1724		T::get().into()
1725	}
1726}
1727
1728impl<T: Config> ServiceQueues for Pallet<T> {
1729	type OverweightMessageAddress = (MessageOriginOf<T>, PageIndex, T::Size);
1730
1731	fn service_queues(weight_limit: Weight) -> Weight {
1732		Self::service_queues_impl(weight_limit, ServiceQueuesContext::ServiceQueues)
1733	}
1734
1735	/// Execute a single overweight message.
1736	///
1737	/// The weight limit must be enough for `execute_overweight` and the message execution itself.
1738	fn execute_overweight(
1739		weight_limit: Weight,
1740		(message_origin, page, index): Self::OverweightMessageAddress,
1741	) -> Result<Weight, ExecuteOverweightError> {
1742		let mut weight = WeightMeter::with_limit(weight_limit);
1743		if weight
1744			.try_consume(
1745				T::WeightInfo::execute_overweight_page_removed()
1746					.max(T::WeightInfo::execute_overweight_page_updated()),
1747			)
1748			.is_err()
1749		{
1750			return Err(ExecuteOverweightError::InsufficientWeight)
1751		}
1752
1753		Pallet::<T>::do_execute_overweight(message_origin, page, index, weight.remaining()).map_err(
1754			|e| match e {
1755				Error::<T>::InsufficientWeight => ExecuteOverweightError::InsufficientWeight,
1756				Error::<T>::AlreadyProcessed => ExecuteOverweightError::AlreadyProcessed,
1757				Error::<T>::QueuePaused => ExecuteOverweightError::QueuePaused,
1758				Error::<T>::NoPage | Error::<T>::NoMessage | Error::<T>::Queued =>
1759					ExecuteOverweightError::NotFound,
1760				Error::<T>::RecursiveDisallowed => ExecuteOverweightError::RecursiveDisallowed,
1761				_ => ExecuteOverweightError::Other,
1762			},
1763		)
1764	}
1765}
1766
1767impl<T: Config> EnqueueMessage<MessageOriginOf<T>> for Pallet<T> {
1768	type MaxMessageLen =
1769		MaxMessageLen<<T::MessageProcessor as ProcessMessage>::Origin, T::Size, T::HeapSize>;
1770
1771	fn enqueue_message(
1772		message: BoundedSlice<u8, Self::MaxMessageLen>,
1773		origin: <T::MessageProcessor as ProcessMessage>::Origin,
1774	) {
1775		Self::do_enqueue_messages(&origin, [message].into_iter());
1776		let book_state = BookStateFor::<T>::get(&origin);
1777		T::QueueChangeHandler::on_queue_changed(origin, book_state.into());
1778	}
1779
1780	fn enqueue_messages<'a>(
1781		messages: impl Iterator<Item = BoundedSlice<'a, u8, Self::MaxMessageLen>>,
1782		origin: <T::MessageProcessor as ProcessMessage>::Origin,
1783	) {
1784		Self::do_enqueue_messages(&origin, messages);
1785		let book_state = BookStateFor::<T>::get(&origin);
1786		T::QueueChangeHandler::on_queue_changed(origin, book_state.into());
1787	}
1788
1789	fn sweep_queue(origin: MessageOriginOf<T>) {
1790		if !BookStateFor::<T>::contains_key(&origin) {
1791			return
1792		}
1793		let mut book_state = BookStateFor::<T>::get(&origin);
1794		book_state.begin = book_state.end;
1795		if let Some(neighbours) = book_state.ready_neighbours.take() {
1796			Self::ready_ring_unknit(&origin, neighbours);
1797		}
1798		BookStateFor::<T>::insert(&origin, &book_state);
1799	}
1800
1801	fn footprint(origin: MessageOriginOf<T>) -> QueueFootprint {
1802		BookStateFor::<T>::get(&origin).into()
1803	}
1804}