@webb-tools/tangle-substrate-types 0.5.12 → 0.9.0

This diff represents the content of publicly available package versions that have been released to one of the supported registries. The information contained in this diff is provided for informational purposes only and reflects changes between package versions as they appear in their respective public registries.
Files changed (36) hide show
  1. package/LICENSE +0 -0
  2. package/README.md +15 -17
  3. package/build/index.cjs +2 -0
  4. package/build/index.d.ts +20826 -0
  5. package/build/index.mjs +1 -0
  6. package/package.json +57 -1
  7. package/examples/job_and_result_submission.d.ts +0 -1
  8. package/examples/job_and_result_submission.js +0 -230
  9. package/index.d.ts +0 -3
  10. package/index.js +0 -5
  11. package/interfaces/augment-api-consts.d.ts +0 -1045
  12. package/interfaces/augment-api-consts.js +0 -3
  13. package/interfaces/augment-api-errors.d.ts +0 -2001
  14. package/interfaces/augment-api-errors.js +0 -3
  15. package/interfaces/augment-api-events.d.ts +0 -3268
  16. package/interfaces/augment-api-events.js +0 -3
  17. package/interfaces/augment-api-query.d.ts +0 -2117
  18. package/interfaces/augment-api-query.js +0 -3
  19. package/interfaces/augment-api-rpc.d.ts +0 -679
  20. package/interfaces/augment-api-rpc.js +0 -3
  21. package/interfaces/augment-api-runtime.d.ts +0 -363
  22. package/interfaces/augment-api-runtime.js +0 -3
  23. package/interfaces/augment-api-tx.d.ts +0 -4118
  24. package/interfaces/augment-api-tx.js +0 -3
  25. package/interfaces/augment-api.d.ts +0 -7
  26. package/interfaces/augment-api.js +0 -9
  27. package/interfaces/augment-types.d.ts +0 -1249
  28. package/interfaces/augment-types.js +0 -3
  29. package/interfaces/lookup.d.ts +0 -6240
  30. package/interfaces/lookup.js +0 -6248
  31. package/interfaces/registry.d.ts +0 -413
  32. package/interfaces/registry.js +0 -3
  33. package/interfaces/types-lookup.d.ts +0 -6157
  34. package/interfaces/types-lookup.js +0 -3
  35. package/metadata/static-latest.d.ts +0 -2
  36. package/metadata/static-latest.js +0 -7
@@ -1,1249 +0,0 @@
1
- import '@polkadot/types/types/registry';
2
- import type { Data, StorageKey } from '@polkadot/types';
3
- import type { BitVec, Bool, Bytes, F32, F64, I128, I16, I256, I32, I64, I8, ISize, Json, Null, OptionBool, Raw, Text, Type, U128, U16, U256, U32, U64, U8, USize, bool, f32, f64, i128, i16, i256, i32, i64, i8, isize, u128, u16, u256, u32, u64, u8, usize } from '@polkadot/types-codec';
4
- import type { TAssetConversion } from '@polkadot/types/interfaces/assetConversion';
5
- import type { AssetApproval, AssetApprovalKey, AssetBalance, AssetDestroyWitness, AssetDetails, AssetMetadata, TAssetBalance, TAssetDepositBalance } from '@polkadot/types/interfaces/assets';
6
- import type { BlockAttestations, IncludedBlocks, MoreAttestations } from '@polkadot/types/interfaces/attestations';
7
- import type { RawAuraPreDigest } from '@polkadot/types/interfaces/aura';
8
- import type { ExtrinsicOrHash, ExtrinsicStatus } from '@polkadot/types/interfaces/author';
9
- import type { UncleEntryItem } from '@polkadot/types/interfaces/authorship';
10
- import type { AllowedSlots, BabeAuthorityWeight, BabeBlockWeight, BabeEpochConfiguration, BabeEquivocationProof, BabeGenesisConfiguration, BabeGenesisConfigurationV1, BabeWeight, Epoch, EpochAuthorship, MaybeRandomness, MaybeVrf, NextConfigDescriptor, NextConfigDescriptorV1, OpaqueKeyOwnershipProof, Randomness, RawBabePreDigest, RawBabePreDigestCompat, RawBabePreDigestPrimary, RawBabePreDigestPrimaryTo159, RawBabePreDigestSecondaryPlain, RawBabePreDigestSecondaryTo159, RawBabePreDigestSecondaryVRF, RawBabePreDigestTo159, SlotNumber, VrfData, VrfOutput, VrfProof } from '@polkadot/types/interfaces/babe';
11
- import type { AccountData, BalanceLock, BalanceLockTo212, BalanceStatus, Reasons, ReserveData, ReserveIdentifier, VestingSchedule, WithdrawReasons } from '@polkadot/types/interfaces/balances';
12
- import type { BeefyAuthoritySet, BeefyCommitment, BeefyCompactSignedCommitment, BeefyEquivocationProof, BeefyId, BeefyNextAuthoritySet, BeefyPayload, BeefyPayloadId, BeefySignedCommitment, BeefyVersionedFinalityProof, BeefyVoteMessage, MmrRootHash, ValidatorSet, ValidatorSetId } from '@polkadot/types/interfaces/beefy';
13
- import type { BenchmarkBatch, BenchmarkConfig, BenchmarkList, BenchmarkMetadata, BenchmarkParameter, BenchmarkResult } from '@polkadot/types/interfaces/benchmark';
14
- import type { CheckInherentsResult, InherentData, InherentIdentifier } from '@polkadot/types/interfaces/blockbuilder';
15
- import type { BridgeMessageId, BridgedBlockHash, BridgedBlockNumber, BridgedHeader, CallOrigin, ChainId, DeliveredMessages, DispatchFeePayment, InboundLaneData, InboundRelayer, InitializationData, LaneId, MessageData, MessageKey, MessageNonce, MessagesDeliveryProofOf, MessagesProofOf, OperatingMode, OutboundLaneData, OutboundMessageFee, OutboundPayload, Parameter, RelayerId, UnrewardedRelayer, UnrewardedRelayersState } from '@polkadot/types/interfaces/bridges';
16
- import type { BlockHash } from '@polkadot/types/interfaces/chain';
17
- import type { PrefixedStorageKey } from '@polkadot/types/interfaces/childstate';
18
- import type { StatementKind } from '@polkadot/types/interfaces/claims';
19
- import type { CollectiveOrigin, MemberCount, ProposalIndex, Votes, VotesTo230 } from '@polkadot/types/interfaces/collective';
20
- import type { AuthorityId, RawVRFOutput } from '@polkadot/types/interfaces/consensus';
21
- import type { AliveContractInfo, CodeHash, CodeSource, CodeUploadRequest, CodeUploadResult, CodeUploadResultValue, ContractCallFlags, ContractCallRequest, ContractExecResult, ContractExecResultOk, ContractExecResultResult, ContractExecResultSuccessTo255, ContractExecResultSuccessTo260, ContractExecResultTo255, ContractExecResultTo260, ContractExecResultTo267, ContractExecResultU64, ContractInfo, ContractInstantiateResult, ContractInstantiateResultTo267, ContractInstantiateResultTo299, ContractInstantiateResultU64, ContractReturnFlags, ContractStorageKey, DeletedContract, ExecReturnValue, Gas, HostFnWeights, HostFnWeightsTo264, InstantiateRequest, InstantiateRequestV1, InstantiateRequestV2, InstantiateReturnValue, InstantiateReturnValueOk, InstantiateReturnValueTo267, InstructionWeights, Limits, LimitsTo264, PrefabWasmModule, RentProjection, Schedule, ScheduleTo212, ScheduleTo258, ScheduleTo264, SeedOf, StorageDeposit, TombstoneContractInfo, TrieId } from '@polkadot/types/interfaces/contracts';
22
- import type { ContractConstructorSpecLatest, ContractConstructorSpecV0, ContractConstructorSpecV1, ContractConstructorSpecV2, ContractConstructorSpecV3, ContractConstructorSpecV4, ContractContractSpecV0, ContractContractSpecV1, ContractContractSpecV2, ContractContractSpecV3, ContractContractSpecV4, ContractContractSpecV5, ContractCryptoHasher, ContractDiscriminant, ContractDisplayName, ContractEnvironmentV4, ContractEventParamSpecLatest, ContractEventParamSpecV0, ContractEventParamSpecV2, ContractEventSpecLatest, ContractEventSpecV0, ContractEventSpecV1, ContractEventSpecV2, ContractEventSpecV3, ContractLayoutArray, ContractLayoutCell, ContractLayoutEnum, ContractLayoutHash, ContractLayoutHashingStrategy, ContractLayoutKey, ContractLayoutStruct, ContractLayoutStructField, ContractMessageParamSpecLatest, ContractMessageParamSpecV0, ContractMessageParamSpecV2, ContractMessageSpecLatest, ContractMessageSpecV0, ContractMessageSpecV1, ContractMessageSpecV2, ContractMessageSpecV3, ContractMetadata, ContractMetadataLatest, ContractMetadataV0, ContractMetadataV1, ContractMetadataV2, ContractMetadataV3, ContractMetadataV4, ContractMetadataV5, ContractProject, ContractProjectContract, ContractProjectInfo, ContractProjectSource, ContractProjectV0, ContractSelector, ContractStorageLayout, ContractTypeSpec } from '@polkadot/types/interfaces/contractsAbi';
23
- import type { FundIndex, FundInfo, LastContribution, TrieIndex } from '@polkadot/types/interfaces/crowdloan';
24
- import type { CollationInfo, CollationInfoV1, ConfigData, MessageId, OverweightIndex, PageCounter, PageIndexData } from '@polkadot/types/interfaces/cumulus';
25
- import type { AccountVote, AccountVoteSplit, AccountVoteStandard, Conviction, Delegations, PreimageStatus, PreimageStatusAvailable, PriorLock, PropIndex, Proposal, ProxyState, ReferendumIndex, ReferendumInfo, ReferendumInfoFinished, ReferendumInfoTo239, ReferendumStatus, Tally, Voting, VotingDelegating, VotingDirect, VotingDirectVote } from '@polkadot/types/interfaces/democracy';
26
- import type { BlockStats } from '@polkadot/types/interfaces/dev';
27
- import type { ApprovalFlag, DefunctVoter, Renouncing, SetIndex, Vote, VoteIndex, VoteThreshold, VoterInfo } from '@polkadot/types/interfaces/elections';
28
- import type { CreatedBlock, ImportedAux } from '@polkadot/types/interfaces/engine';
29
- import type { BlockV0, BlockV1, BlockV2, EIP1559Transaction, EIP2930Transaction, EthAccessList, EthAccessListItem, EthAccount, EthAddress, EthBlock, EthBloom, EthCallRequest, EthFeeHistory, EthFilter, EthFilterAddress, EthFilterChanges, EthFilterTopic, EthFilterTopicEntry, EthFilterTopicInner, EthHeader, EthLog, EthReceipt, EthReceiptV0, EthReceiptV3, EthRichBlock, EthRichHeader, EthStorageProof, EthSubKind, EthSubParams, EthSubResult, EthSyncInfo, EthSyncStatus, EthTransaction, EthTransactionAction, EthTransactionCondition, EthTransactionRequest, EthTransactionSignature, EthTransactionStatus, EthWork, EthereumAccountId, EthereumAddress, EthereumLookupSource, EthereumSignature, LegacyTransaction, TransactionV0, TransactionV1, TransactionV2 } from '@polkadot/types/interfaces/eth';
30
- import type { EvmAccount, EvmCallInfo, EvmCallInfoV2, EvmCreateInfo, EvmCreateInfoV2, EvmLog, EvmVicinity, EvmWeightInfo, ExitError, ExitFatal, ExitReason, ExitRevert, ExitSucceed } from '@polkadot/types/interfaces/evm';
31
- import type { AnySignature, EcdsaSignature, Ed25519Signature, Era, Extrinsic, ExtrinsicEra, ExtrinsicPayload, ExtrinsicPayloadUnknown, ExtrinsicPayloadV4, ExtrinsicSignature, ExtrinsicSignatureV4, ExtrinsicUnknown, ExtrinsicV4, ImmortalEra, MortalEra, MultiSignature, Signature, SignerPayload, Sr25519Signature } from '@polkadot/types/interfaces/extrinsics';
32
- import type { FungiblesAccessError } from '@polkadot/types/interfaces/fungibles';
33
- import type { AssetOptions, Owner, PermissionLatest, PermissionVersions, PermissionsV1 } from '@polkadot/types/interfaces/genericAsset';
34
- import type { GenesisBuildErr } from '@polkadot/types/interfaces/genesisBuilder';
35
- import type { ActiveGilt, ActiveGiltsTotal, ActiveIndex, GiltBid } from '@polkadot/types/interfaces/gilt';
36
- import type { AuthorityIndex, AuthorityList, AuthoritySet, AuthoritySetChange, AuthoritySetChanges, AuthorityWeight, DelayKind, DelayKindBest, EncodedFinalityProofs, ForkTreePendingChange, ForkTreePendingChangeNode, GrandpaCommit, GrandpaEquivocation, GrandpaEquivocationProof, GrandpaEquivocationValue, GrandpaJustification, GrandpaPrecommit, GrandpaPrevote, GrandpaSignedPrecommit, JustificationNotification, KeyOwnerProof, NextAuthority, PendingChange, PendingPause, PendingResume, Precommits, Prevotes, ReportedRoundStates, RoundState, SetId, StoredPendingChange, StoredState } from '@polkadot/types/interfaces/grandpa';
37
- import type { IdentityFields, IdentityInfo, IdentityInfoAdditional, IdentityInfoTo198, IdentityJudgement, RegistrarIndex, RegistrarInfo, Registration, RegistrationJudgement, RegistrationTo198 } from '@polkadot/types/interfaces/identity';
38
- import type { AuthIndex, AuthoritySignature, Heartbeat, HeartbeatTo244, OpaqueMultiaddr, OpaqueNetworkState, OpaquePeerId } from '@polkadot/types/interfaces/imOnline';
39
- import type { CallIndex, LotteryConfig } from '@polkadot/types/interfaces/lottery';
40
- import type { CustomMetadata15, CustomValueMetadata15, ErrorMetadataLatest, ErrorMetadataV10, ErrorMetadataV11, ErrorMetadataV12, ErrorMetadataV13, ErrorMetadataV14, ErrorMetadataV9, EventMetadataLatest, EventMetadataV10, EventMetadataV11, EventMetadataV12, EventMetadataV13, EventMetadataV14, EventMetadataV9, ExtrinsicMetadataLatest, ExtrinsicMetadataV11, ExtrinsicMetadataV12, ExtrinsicMetadataV13, ExtrinsicMetadataV14, ExtrinsicMetadataV15, FunctionArgumentMetadataLatest, FunctionArgumentMetadataV10, FunctionArgumentMetadataV11, FunctionArgumentMetadataV12, FunctionArgumentMetadataV13, FunctionArgumentMetadataV14, FunctionArgumentMetadataV9, FunctionMetadataLatest, FunctionMetadataV10, FunctionMetadataV11, FunctionMetadataV12, FunctionMetadataV13, FunctionMetadataV14, FunctionMetadataV9, MetadataAll, MetadataLatest, MetadataV10, MetadataV11, MetadataV12, MetadataV13, MetadataV14, MetadataV15, MetadataV9, ModuleConstantMetadataV10, ModuleConstantMetadataV11, ModuleConstantMetadataV12, ModuleConstantMetadataV13, ModuleConstantMetadataV9, ModuleMetadataV10, ModuleMetadataV11, ModuleMetadataV12, ModuleMetadataV13, ModuleMetadataV9, OpaqueMetadata, OuterEnums15, PalletCallMetadataLatest, PalletCallMetadataV14, PalletConstantMetadataLatest, PalletConstantMetadataV14, PalletErrorMetadataLatest, PalletErrorMetadataV14, PalletEventMetadataLatest, PalletEventMetadataV14, PalletMetadataLatest, PalletMetadataV14, PalletMetadataV15, PalletStorageMetadataLatest, PalletStorageMetadataV14, PortableType, PortableTypeV14, RuntimeApiMetadataLatest, RuntimeApiMetadataV15, RuntimeApiMethodMetadataV15, RuntimeApiMethodParamMetadataV15, SignedExtensionMetadataLatest, SignedExtensionMetadataV14, StorageEntryMetadataLatest, StorageEntryMetadataV10, StorageEntryMetadataV11, StorageEntryMetadataV12, StorageEntryMetadataV13, StorageEntryMetadataV14, StorageEntryMetadataV9, StorageEntryModifierLatest, StorageEntryModifierV10, StorageEntryModifierV11, StorageEntryModifierV12, StorageEntryModifierV13, StorageEntryModifierV14, StorageEntryModifierV9, StorageEntryTypeLatest, StorageEntryTypeV10, StorageEntryTypeV11, StorageEntryTypeV12, StorageEntryTypeV13, StorageEntryTypeV14, StorageEntryTypeV9, StorageHasher, StorageHasherV10, StorageHasherV11, StorageHasherV12, StorageHasherV13, StorageHasherV14, StorageHasherV9, StorageMetadataV10, StorageMetadataV11, StorageMetadataV12, StorageMetadataV13, StorageMetadataV9 } from '@polkadot/types/interfaces/metadata';
41
- import type { Mixnode, MixnodesErr, SessionPhase, SessionStatus } from '@polkadot/types/interfaces/mixnet';
42
- import type { MmrBatchProof, MmrEncodableOpaqueLeaf, MmrError, MmrHash, MmrLeafBatchProof, MmrLeafIndex, MmrLeafProof, MmrNodeIndex, MmrProof } from '@polkadot/types/interfaces/mmr';
43
- import type { NftCollectionId, NftItemId } from '@polkadot/types/interfaces/nfts';
44
- import type { NpApiError, NpPoolId } from '@polkadot/types/interfaces/nompools';
45
- import type { StorageKind } from '@polkadot/types/interfaces/offchain';
46
- import type { DeferredOffenceOf, Kind, OffenceDetails, Offender, OpaqueTimeSlot, ReportIdOf, Reporter } from '@polkadot/types/interfaces/offences';
47
- import type { AbridgedCandidateReceipt, AbridgedHostConfiguration, AbridgedHrmpChannel, ApprovalVotingParams, AssignmentId, AssignmentKind, AsyncBackingParams, AttestedCandidate, AuctionIndex, AuthorityDiscoveryId, AvailabilityBitfield, AvailabilityBitfieldRecord, BackedCandidate, BackingState, Bidder, BufferedSessionChange, CandidateCommitments, CandidateDescriptor, CandidateEvent, CandidateHash, CandidateInfo, CandidatePendingAvailability, CandidateReceipt, CollatorId, CollatorSignature, CommittedCandidateReceipt, Constraints, CoreAssignment, CoreIndex, CoreOccupied, CoreState, DisputeLocation, DisputeProof, DisputeResult, DisputeState, DisputeStatement, DisputeStatementSet, DisputesTimeSlot, DoubleVoteReport, DownwardMessage, ExecutorParam, ExecutorParams, ExecutorParamsHash, ExplicitDisputeStatement, GlobalValidationData, GlobalValidationSchedule, GroupIndex, GroupRotationInfo, HeadData, HostConfiguration, HrmpChannel, HrmpChannelId, HrmpOpenChannelRequest, InboundDownwardMessage, InboundHrmpLimitations, InboundHrmpMessage, InboundHrmpMessages, IncomingParachain, IncomingParachainDeploy, IncomingParachainFixed, InvalidDisputeStatementKind, LeasePeriod, LeasePeriodOf, LocalValidationData, MessageIngestionType, MessageQueueChain, MessagingStateSnapshot, MessagingStateSnapshotEgressEntry, MultiDisputeStatementSet, NewBidder, NodeFeatures, OccupiedCore, OccupiedCoreAssumption, OldV1SessionInfo, OutboundHrmpChannelLimitations, OutboundHrmpMessage, ParaGenesisArgs, ParaId, ParaInfo, ParaLifecycle, ParaPastCodeMeta, ParaScheduling, ParaValidatorIndex, ParachainDispatchOrigin, ParachainInherentData, ParachainProposal, ParachainsInherentData, ParathreadClaim, ParathreadClaimQueue, ParathreadEntry, PendingSlashes, PersistedValidationData, PvfCheckStatement, PvfExecTimeoutKind, PvfPrepTimeoutKind, QueuedParathread, RegisteredParachainInfo, RelayBlockNumber, RelayChainBlockNumber, RelayChainHash, RelayHash, Remark, ReplacementTimes, Retriable, ScheduledCore, Scheduling, ScrapedOnChainVotes, ServiceQuality, SessionInfo, SessionInfoValidatorGroup, SignedAvailabilityBitfield, SignedAvailabilityBitfields, SigningContext, SlashingOffenceKind, SlotRange, SlotRange10, Statement, SubId, SystemInherentData, TransientValidationData, UpgradeGoAhead, UpgradeRestriction, UpwardMessage, ValidDisputeStatementKind, ValidationCode, ValidationCodeHash, ValidationData, ValidationDataType, ValidationFunctionParams, ValidatorSignature, ValidityAttestation, VecInboundHrmpMessage, WinnersData, WinnersData10, WinnersDataTuple, WinnersDataTuple10, WinningData, WinningData10, WinningDataEntry } from '@polkadot/types/interfaces/parachains';
48
- import type { FeeDetails, InclusionFee, RuntimeDispatchInfo, RuntimeDispatchInfoV1, RuntimeDispatchInfoV2 } from '@polkadot/types/interfaces/payment';
49
- import type { Approvals } from '@polkadot/types/interfaces/poll';
50
- import type { ProxyAnnouncement, ProxyDefinition, ProxyType } from '@polkadot/types/interfaces/proxy';
51
- import type { AccountStatus, AccountValidity } from '@polkadot/types/interfaces/purchase';
52
- import type { ActiveRecovery, RecoveryConfig } from '@polkadot/types/interfaces/recovery';
53
- import type { RpcMethods } from '@polkadot/types/interfaces/rpc';
54
- import type { AccountId, AccountId20, AccountId32, AccountId33, AccountIdOf, AccountIndex, Address, AssetId, Balance, BalanceOf, Block, BlockNumber, BlockNumberFor, BlockNumberOf, Call, CallHash, CallHashOf, ChangesTrieConfiguration, ChangesTrieSignal, CodecHash, Consensus, ConsensusEngineId, CrateVersion, Digest, DigestItem, EncodedJustification, ExtrinsicInclusionMode, ExtrinsicsWeight, Fixed128, Fixed64, FixedI128, FixedI64, FixedU128, FixedU64, H1024, H128, H160, H2048, H256, H32, H512, H64, Hash, Header, HeaderPartial, I32F32, Index, IndicesLookupSource, Justification, Justifications, KeyTypeId, KeyValue, LockIdentifier, LookupSource, LookupTarget, ModuleId, Moment, MultiAddress, MultiSigner, OpaqueCall, Origin, OriginCaller, PalletId, PalletVersion, PalletsOrigin, Pays, PerU16, Perbill, Percent, Permill, Perquintill, Phantom, PhantomData, PreRuntime, Releases, RuntimeCall, RuntimeDbWeight, RuntimeEvent, Seal, SealV0, SignedBlock, SignedBlockWithJustification, SignedBlockWithJustifications, Slot, SlotDuration, StorageData, StorageInfo, StorageProof, TransactionInfo, TransactionLongevity, TransactionPriority, TransactionStorageProof, TransactionTag, U32F32, ValidatorId, ValidatorIdOf, Weight, WeightMultiplier, WeightV0, WeightV1, WeightV2 } from '@polkadot/types/interfaces/runtime';
55
- import type { Si0Field, Si0LookupTypeId, Si0Path, Si0Type, Si0TypeDef, Si0TypeDefArray, Si0TypeDefBitSequence, Si0TypeDefCompact, Si0TypeDefComposite, Si0TypeDefPhantom, Si0TypeDefPrimitive, Si0TypeDefSequence, Si0TypeDefTuple, Si0TypeDefVariant, Si0TypeParameter, Si0Variant, Si1Field, Si1LookupTypeId, Si1Path, Si1Type, Si1TypeDef, Si1TypeDefArray, Si1TypeDefBitSequence, Si1TypeDefCompact, Si1TypeDefComposite, Si1TypeDefPrimitive, Si1TypeDefSequence, Si1TypeDefTuple, Si1TypeDefVariant, Si1TypeParameter, Si1Variant, SiField, SiLookupTypeId, SiPath, SiType, SiTypeDef, SiTypeDefArray, SiTypeDefBitSequence, SiTypeDefCompact, SiTypeDefComposite, SiTypeDefPrimitive, SiTypeDefSequence, SiTypeDefTuple, SiTypeDefVariant, SiTypeParameter, SiVariant } from '@polkadot/types/interfaces/scaleInfo';
56
- import type { Period, Priority, SchedulePeriod, SchedulePriority, Scheduled, ScheduledTo254, TaskAddress } from '@polkadot/types/interfaces/scheduler';
57
- import type { BeefyKey, FullIdentification, IdentificationTuple, Keys, MembershipProof, SessionIndex, SessionKeys1, SessionKeys10, SessionKeys10B, SessionKeys2, SessionKeys3, SessionKeys4, SessionKeys5, SessionKeys6, SessionKeys6B, SessionKeys7, SessionKeys7B, SessionKeys8, SessionKeys8B, SessionKeys9, SessionKeys9B, ValidatorCount } from '@polkadot/types/interfaces/session';
58
- import type { Bid, BidKind, SocietyJudgement, SocietyVote, StrikeCount, VouchingStatus } from '@polkadot/types/interfaces/society';
59
- import type { ActiveEraInfo, CompactAssignments, CompactAssignmentsTo257, CompactAssignmentsTo265, CompactAssignmentsWith16, CompactAssignmentsWith24, CompactScore, CompactScoreCompact, ElectionCompute, ElectionPhase, ElectionResult, ElectionScore, ElectionSize, ElectionStatus, EraIndex, EraPoints, EraRewardPoints, EraRewards, Exposure, ExtendedBalance, Forcing, IndividualExposure, KeyType, MomentOf, Nominations, NominatorIndex, NominatorIndexCompact, OffchainAccuracy, OffchainAccuracyCompact, PhragmenScore, Points, RawSolution, RawSolutionTo265, RawSolutionWith16, RawSolutionWith24, ReadySolution, RewardDestination, RewardPoint, RoundSnapshot, SeatHolder, SignedSubmission, SignedSubmissionOf, SignedSubmissionTo276, SlashJournalEntry, SlashingSpans, SlashingSpansTo204, SolutionOrSnapshotSize, SolutionSupport, SolutionSupports, SpanIndex, SpanRecord, StakingLedger, StakingLedgerTo223, StakingLedgerTo240, SubmissionIndicesOf, Supports, UnappliedSlash, UnappliedSlashOther, UnlockChunk, ValidatorIndex, ValidatorIndexCompact, ValidatorPrefs, ValidatorPrefsTo145, ValidatorPrefsTo196, ValidatorPrefsWithBlocked, ValidatorPrefsWithCommission, VoteWeight, Voter } from '@polkadot/types/interfaces/staking';
60
- import type { ApiId, BlockTrace, BlockTraceEvent, BlockTraceEventData, BlockTraceSpan, KeyValueOption, MigrationStatusResult, ReadProof, RuntimeVersion, RuntimeVersionApi, RuntimeVersionPartial, RuntimeVersionPre3, RuntimeVersionPre4, SpecVersion, StorageChangeSet, TraceBlockResponse, TraceError } from '@polkadot/types/interfaces/state';
61
- import type { StatementStoreInvalidStatement, StatementStoreStatementSource, StatementStoreValidStatement } from '@polkadot/types/interfaces/statement';
62
- import type { WeightToFeeCoefficient } from '@polkadot/types/interfaces/support';
63
- import type { AccountInfo, AccountInfoWithDualRefCount, AccountInfoWithProviders, AccountInfoWithRefCount, AccountInfoWithRefCountU8, AccountInfoWithTripleRefCount, ApplyExtrinsicResult, ApplyExtrinsicResultPre6, ArithmeticError, BlockLength, BlockWeights, ChainProperties, ChainType, ConsumedWeight, DigestOf, DispatchClass, DispatchError, DispatchErrorModule, DispatchErrorModulePre6, DispatchErrorModuleU8, DispatchErrorModuleU8a, DispatchErrorPre6, DispatchErrorPre6First, DispatchErrorTo198, DispatchInfo, DispatchInfoTo190, DispatchInfoTo244, DispatchOutcome, DispatchOutcomePre6, DispatchResult, DispatchResultOf, DispatchResultTo198, Event, EventId, EventIndex, EventRecord, Health, InvalidTransaction, Key, LastRuntimeUpgradeInfo, NetworkState, NetworkStatePeerset, NetworkStatePeersetInfo, NodeRole, NotConnectedPeer, Peer, PeerEndpoint, PeerEndpointAddr, PeerInfo, PeerPing, PerDispatchClassU32, PerDispatchClassWeight, PerDispatchClassWeightsPerClass, Phase, RawOrigin, RefCount, RefCountTo259, SyncState, SystemOrigin, TokenError, TransactionValidityError, TransactionalError, UnknownTransaction, WeightPerClass } from '@polkadot/types/interfaces/system';
64
- import type { Bounty, BountyIndex, BountyStatus, BountyStatusActive, BountyStatusCuratorProposed, BountyStatusPendingPayout, OpenTip, OpenTipFinderTo225, OpenTipTip, OpenTipTo225, TreasuryProposal } from '@polkadot/types/interfaces/treasury';
65
- import type { Multiplier } from '@polkadot/types/interfaces/txpayment';
66
- import type { TransactionSource, TransactionValidity, ValidTransaction } from '@polkadot/types/interfaces/txqueue';
67
- import type { ClassDetails, ClassId, ClassMetadata, DepositBalance, DepositBalanceOf, DestroyWitness, InstanceDetails, InstanceId, InstanceMetadata } from '@polkadot/types/interfaces/uniques';
68
- import type { Multisig, Timepoint } from '@polkadot/types/interfaces/utility';
69
- import type { VestingInfo } from '@polkadot/types/interfaces/vesting';
70
- import type { AssetInstance, AssetInstanceV0, AssetInstanceV1, AssetInstanceV2, BodyId, BodyPart, DoubleEncodedCall, Fungibility, FungibilityV0, FungibilityV1, FungibilityV2, InboundStatus, InstructionV2, InteriorMultiLocation, Junction, JunctionV0, JunctionV1, JunctionV2, Junctions, JunctionsV1, JunctionsV2, MultiAsset, MultiAssetFilter, MultiAssetFilterV1, MultiAssetFilterV2, MultiAssetV0, MultiAssetV1, MultiAssetV2, MultiAssets, MultiAssetsV1, MultiAssetsV2, MultiLocation, MultiLocationV0, MultiLocationV1, MultiLocationV2, NetworkId, OriginKindV0, OriginKindV1, OriginKindV2, OutboundStatus, Outcome, QueryId, QueryStatus, QueueConfigData, Response, ResponseV0, ResponseV1, ResponseV2, ResponseV2Error, ResponseV2Result, VersionMigrationStage, VersionedMultiAsset, VersionedMultiAssets, VersionedMultiLocation, VersionedResponse, VersionedXcm, WeightLimitV2, WildFungibility, WildFungibilityV0, WildFungibilityV1, WildFungibilityV2, WildMultiAsset, WildMultiAssetV1, WildMultiAssetV2, Xcm, XcmAssetId, XcmError, XcmErrorV0, XcmErrorV1, XcmErrorV2, XcmOrder, XcmOrderV0, XcmOrderV1, XcmOrderV2, XcmOrigin, XcmOriginKind, XcmV0, XcmV1, XcmV2, XcmVersion, XcmpMessageFormat } from '@polkadot/types/interfaces/xcm';
71
- declare module '@polkadot/types/types/registry' {
72
- interface InterfaceTypes {
73
- AbridgedCandidateReceipt: AbridgedCandidateReceipt;
74
- AbridgedHostConfiguration: AbridgedHostConfiguration;
75
- AbridgedHrmpChannel: AbridgedHrmpChannel;
76
- AccountData: AccountData;
77
- AccountId: AccountId;
78
- AccountId20: AccountId20;
79
- AccountId32: AccountId32;
80
- AccountId33: AccountId33;
81
- AccountIdOf: AccountIdOf;
82
- AccountIndex: AccountIndex;
83
- AccountInfo: AccountInfo;
84
- AccountInfoWithDualRefCount: AccountInfoWithDualRefCount;
85
- AccountInfoWithProviders: AccountInfoWithProviders;
86
- AccountInfoWithRefCount: AccountInfoWithRefCount;
87
- AccountInfoWithRefCountU8: AccountInfoWithRefCountU8;
88
- AccountInfoWithTripleRefCount: AccountInfoWithTripleRefCount;
89
- AccountStatus: AccountStatus;
90
- AccountValidity: AccountValidity;
91
- AccountVote: AccountVote;
92
- AccountVoteSplit: AccountVoteSplit;
93
- AccountVoteStandard: AccountVoteStandard;
94
- ActiveEraInfo: ActiveEraInfo;
95
- ActiveGilt: ActiveGilt;
96
- ActiveGiltsTotal: ActiveGiltsTotal;
97
- ActiveIndex: ActiveIndex;
98
- ActiveRecovery: ActiveRecovery;
99
- Address: Address;
100
- AliveContractInfo: AliveContractInfo;
101
- AllowedSlots: AllowedSlots;
102
- AnySignature: AnySignature;
103
- ApiId: ApiId;
104
- ApplyExtrinsicResult: ApplyExtrinsicResult;
105
- ApplyExtrinsicResultPre6: ApplyExtrinsicResultPre6;
106
- ApprovalFlag: ApprovalFlag;
107
- Approvals: Approvals;
108
- ApprovalVotingParams: ApprovalVotingParams;
109
- ArithmeticError: ArithmeticError;
110
- AssetApproval: AssetApproval;
111
- AssetApprovalKey: AssetApprovalKey;
112
- AssetBalance: AssetBalance;
113
- AssetDestroyWitness: AssetDestroyWitness;
114
- AssetDetails: AssetDetails;
115
- AssetId: AssetId;
116
- AssetInstance: AssetInstance;
117
- AssetInstanceV0: AssetInstanceV0;
118
- AssetInstanceV1: AssetInstanceV1;
119
- AssetInstanceV2: AssetInstanceV2;
120
- AssetMetadata: AssetMetadata;
121
- AssetOptions: AssetOptions;
122
- AssignmentId: AssignmentId;
123
- AssignmentKind: AssignmentKind;
124
- AsyncBackingParams: AsyncBackingParams;
125
- AttestedCandidate: AttestedCandidate;
126
- AuctionIndex: AuctionIndex;
127
- AuthIndex: AuthIndex;
128
- AuthorityDiscoveryId: AuthorityDiscoveryId;
129
- AuthorityId: AuthorityId;
130
- AuthorityIndex: AuthorityIndex;
131
- AuthorityList: AuthorityList;
132
- AuthoritySet: AuthoritySet;
133
- AuthoritySetChange: AuthoritySetChange;
134
- AuthoritySetChanges: AuthoritySetChanges;
135
- AuthoritySignature: AuthoritySignature;
136
- AuthorityWeight: AuthorityWeight;
137
- AvailabilityBitfield: AvailabilityBitfield;
138
- AvailabilityBitfieldRecord: AvailabilityBitfieldRecord;
139
- BabeAuthorityWeight: BabeAuthorityWeight;
140
- BabeBlockWeight: BabeBlockWeight;
141
- BabeEpochConfiguration: BabeEpochConfiguration;
142
- BabeEquivocationProof: BabeEquivocationProof;
143
- BabeGenesisConfiguration: BabeGenesisConfiguration;
144
- BabeGenesisConfigurationV1: BabeGenesisConfigurationV1;
145
- BabeWeight: BabeWeight;
146
- BackedCandidate: BackedCandidate;
147
- BackingState: BackingState;
148
- Balance: Balance;
149
- BalanceLock: BalanceLock;
150
- BalanceLockTo212: BalanceLockTo212;
151
- BalanceOf: BalanceOf;
152
- BalanceStatus: BalanceStatus;
153
- BeefyAuthoritySet: BeefyAuthoritySet;
154
- BeefyCommitment: BeefyCommitment;
155
- BeefyCompactSignedCommitment: BeefyCompactSignedCommitment;
156
- BeefyEquivocationProof: BeefyEquivocationProof;
157
- BeefyId: BeefyId;
158
- BeefyKey: BeefyKey;
159
- BeefyNextAuthoritySet: BeefyNextAuthoritySet;
160
- BeefyPayload: BeefyPayload;
161
- BeefyPayloadId: BeefyPayloadId;
162
- BeefySignedCommitment: BeefySignedCommitment;
163
- BeefyVersionedFinalityProof: BeefyVersionedFinalityProof;
164
- BeefyVoteMessage: BeefyVoteMessage;
165
- BenchmarkBatch: BenchmarkBatch;
166
- BenchmarkConfig: BenchmarkConfig;
167
- BenchmarkList: BenchmarkList;
168
- BenchmarkMetadata: BenchmarkMetadata;
169
- BenchmarkParameter: BenchmarkParameter;
170
- BenchmarkResult: BenchmarkResult;
171
- Bid: Bid;
172
- Bidder: Bidder;
173
- BidKind: BidKind;
174
- BitVec: BitVec;
175
- Block: Block;
176
- BlockAttestations: BlockAttestations;
177
- BlockHash: BlockHash;
178
- BlockLength: BlockLength;
179
- BlockNumber: BlockNumber;
180
- BlockNumberFor: BlockNumberFor;
181
- BlockNumberOf: BlockNumberOf;
182
- BlockStats: BlockStats;
183
- BlockTrace: BlockTrace;
184
- BlockTraceEvent: BlockTraceEvent;
185
- BlockTraceEventData: BlockTraceEventData;
186
- BlockTraceSpan: BlockTraceSpan;
187
- BlockV0: BlockV0;
188
- BlockV1: BlockV1;
189
- BlockV2: BlockV2;
190
- BlockWeights: BlockWeights;
191
- BodyId: BodyId;
192
- BodyPart: BodyPart;
193
- bool: bool;
194
- Bool: Bool;
195
- Bounty: Bounty;
196
- BountyIndex: BountyIndex;
197
- BountyStatus: BountyStatus;
198
- BountyStatusActive: BountyStatusActive;
199
- BountyStatusCuratorProposed: BountyStatusCuratorProposed;
200
- BountyStatusPendingPayout: BountyStatusPendingPayout;
201
- BridgedBlockHash: BridgedBlockHash;
202
- BridgedBlockNumber: BridgedBlockNumber;
203
- BridgedHeader: BridgedHeader;
204
- BridgeMessageId: BridgeMessageId;
205
- BufferedSessionChange: BufferedSessionChange;
206
- Bytes: Bytes;
207
- Call: Call;
208
- CallHash: CallHash;
209
- CallHashOf: CallHashOf;
210
- CallIndex: CallIndex;
211
- CallOrigin: CallOrigin;
212
- CandidateCommitments: CandidateCommitments;
213
- CandidateDescriptor: CandidateDescriptor;
214
- CandidateEvent: CandidateEvent;
215
- CandidateHash: CandidateHash;
216
- CandidateInfo: CandidateInfo;
217
- CandidatePendingAvailability: CandidatePendingAvailability;
218
- CandidateReceipt: CandidateReceipt;
219
- ChainId: ChainId;
220
- ChainProperties: ChainProperties;
221
- ChainType: ChainType;
222
- ChangesTrieConfiguration: ChangesTrieConfiguration;
223
- ChangesTrieSignal: ChangesTrieSignal;
224
- CheckInherentsResult: CheckInherentsResult;
225
- ClassDetails: ClassDetails;
226
- ClassId: ClassId;
227
- ClassMetadata: ClassMetadata;
228
- CodecHash: CodecHash;
229
- CodeHash: CodeHash;
230
- CodeSource: CodeSource;
231
- CodeUploadRequest: CodeUploadRequest;
232
- CodeUploadResult: CodeUploadResult;
233
- CodeUploadResultValue: CodeUploadResultValue;
234
- CollationInfo: CollationInfo;
235
- CollationInfoV1: CollationInfoV1;
236
- CollatorId: CollatorId;
237
- CollatorSignature: CollatorSignature;
238
- CollectiveOrigin: CollectiveOrigin;
239
- CommittedCandidateReceipt: CommittedCandidateReceipt;
240
- CompactAssignments: CompactAssignments;
241
- CompactAssignmentsTo257: CompactAssignmentsTo257;
242
- CompactAssignmentsTo265: CompactAssignmentsTo265;
243
- CompactAssignmentsWith16: CompactAssignmentsWith16;
244
- CompactAssignmentsWith24: CompactAssignmentsWith24;
245
- CompactScore: CompactScore;
246
- CompactScoreCompact: CompactScoreCompact;
247
- ConfigData: ConfigData;
248
- Consensus: Consensus;
249
- ConsensusEngineId: ConsensusEngineId;
250
- Constraints: Constraints;
251
- ConsumedWeight: ConsumedWeight;
252
- ContractCallFlags: ContractCallFlags;
253
- ContractCallRequest: ContractCallRequest;
254
- ContractConstructorSpecLatest: ContractConstructorSpecLatest;
255
- ContractConstructorSpecV0: ContractConstructorSpecV0;
256
- ContractConstructorSpecV1: ContractConstructorSpecV1;
257
- ContractConstructorSpecV2: ContractConstructorSpecV2;
258
- ContractConstructorSpecV3: ContractConstructorSpecV3;
259
- ContractConstructorSpecV4: ContractConstructorSpecV4;
260
- ContractContractSpecV0: ContractContractSpecV0;
261
- ContractContractSpecV1: ContractContractSpecV1;
262
- ContractContractSpecV2: ContractContractSpecV2;
263
- ContractContractSpecV3: ContractContractSpecV3;
264
- ContractContractSpecV4: ContractContractSpecV4;
265
- ContractContractSpecV5: ContractContractSpecV5;
266
- ContractCryptoHasher: ContractCryptoHasher;
267
- ContractDiscriminant: ContractDiscriminant;
268
- ContractDisplayName: ContractDisplayName;
269
- ContractEnvironmentV4: ContractEnvironmentV4;
270
- ContractEventParamSpecLatest: ContractEventParamSpecLatest;
271
- ContractEventParamSpecV0: ContractEventParamSpecV0;
272
- ContractEventParamSpecV2: ContractEventParamSpecV2;
273
- ContractEventSpecLatest: ContractEventSpecLatest;
274
- ContractEventSpecV0: ContractEventSpecV0;
275
- ContractEventSpecV1: ContractEventSpecV1;
276
- ContractEventSpecV2: ContractEventSpecV2;
277
- ContractEventSpecV3: ContractEventSpecV3;
278
- ContractExecResult: ContractExecResult;
279
- ContractExecResultOk: ContractExecResultOk;
280
- ContractExecResultResult: ContractExecResultResult;
281
- ContractExecResultSuccessTo255: ContractExecResultSuccessTo255;
282
- ContractExecResultSuccessTo260: ContractExecResultSuccessTo260;
283
- ContractExecResultTo255: ContractExecResultTo255;
284
- ContractExecResultTo260: ContractExecResultTo260;
285
- ContractExecResultTo267: ContractExecResultTo267;
286
- ContractExecResultU64: ContractExecResultU64;
287
- ContractInfo: ContractInfo;
288
- ContractInstantiateResult: ContractInstantiateResult;
289
- ContractInstantiateResultTo267: ContractInstantiateResultTo267;
290
- ContractInstantiateResultTo299: ContractInstantiateResultTo299;
291
- ContractInstantiateResultU64: ContractInstantiateResultU64;
292
- ContractLayoutArray: ContractLayoutArray;
293
- ContractLayoutCell: ContractLayoutCell;
294
- ContractLayoutEnum: ContractLayoutEnum;
295
- ContractLayoutHash: ContractLayoutHash;
296
- ContractLayoutHashingStrategy: ContractLayoutHashingStrategy;
297
- ContractLayoutKey: ContractLayoutKey;
298
- ContractLayoutStruct: ContractLayoutStruct;
299
- ContractLayoutStructField: ContractLayoutStructField;
300
- ContractMessageParamSpecLatest: ContractMessageParamSpecLatest;
301
- ContractMessageParamSpecV0: ContractMessageParamSpecV0;
302
- ContractMessageParamSpecV2: ContractMessageParamSpecV2;
303
- ContractMessageSpecLatest: ContractMessageSpecLatest;
304
- ContractMessageSpecV0: ContractMessageSpecV0;
305
- ContractMessageSpecV1: ContractMessageSpecV1;
306
- ContractMessageSpecV2: ContractMessageSpecV2;
307
- ContractMessageSpecV3: ContractMessageSpecV3;
308
- ContractMetadata: ContractMetadata;
309
- ContractMetadataLatest: ContractMetadataLatest;
310
- ContractMetadataV0: ContractMetadataV0;
311
- ContractMetadataV1: ContractMetadataV1;
312
- ContractMetadataV2: ContractMetadataV2;
313
- ContractMetadataV3: ContractMetadataV3;
314
- ContractMetadataV4: ContractMetadataV4;
315
- ContractMetadataV5: ContractMetadataV5;
316
- ContractProject: ContractProject;
317
- ContractProjectContract: ContractProjectContract;
318
- ContractProjectInfo: ContractProjectInfo;
319
- ContractProjectSource: ContractProjectSource;
320
- ContractProjectV0: ContractProjectV0;
321
- ContractReturnFlags: ContractReturnFlags;
322
- ContractSelector: ContractSelector;
323
- ContractStorageKey: ContractStorageKey;
324
- ContractStorageLayout: ContractStorageLayout;
325
- ContractTypeSpec: ContractTypeSpec;
326
- Conviction: Conviction;
327
- CoreAssignment: CoreAssignment;
328
- CoreIndex: CoreIndex;
329
- CoreOccupied: CoreOccupied;
330
- CoreState: CoreState;
331
- CrateVersion: CrateVersion;
332
- CreatedBlock: CreatedBlock;
333
- CustomMetadata15: CustomMetadata15;
334
- CustomValueMetadata15: CustomValueMetadata15;
335
- Data: Data;
336
- DeferredOffenceOf: DeferredOffenceOf;
337
- DefunctVoter: DefunctVoter;
338
- DelayKind: DelayKind;
339
- DelayKindBest: DelayKindBest;
340
- Delegations: Delegations;
341
- DeletedContract: DeletedContract;
342
- DeliveredMessages: DeliveredMessages;
343
- DepositBalance: DepositBalance;
344
- DepositBalanceOf: DepositBalanceOf;
345
- DestroyWitness: DestroyWitness;
346
- Digest: Digest;
347
- DigestItem: DigestItem;
348
- DigestOf: DigestOf;
349
- DispatchClass: DispatchClass;
350
- DispatchError: DispatchError;
351
- DispatchErrorModule: DispatchErrorModule;
352
- DispatchErrorModulePre6: DispatchErrorModulePre6;
353
- DispatchErrorModuleU8: DispatchErrorModuleU8;
354
- DispatchErrorModuleU8a: DispatchErrorModuleU8a;
355
- DispatchErrorPre6: DispatchErrorPre6;
356
- DispatchErrorPre6First: DispatchErrorPre6First;
357
- DispatchErrorTo198: DispatchErrorTo198;
358
- DispatchFeePayment: DispatchFeePayment;
359
- DispatchInfo: DispatchInfo;
360
- DispatchInfoTo190: DispatchInfoTo190;
361
- DispatchInfoTo244: DispatchInfoTo244;
362
- DispatchOutcome: DispatchOutcome;
363
- DispatchOutcomePre6: DispatchOutcomePre6;
364
- DispatchResult: DispatchResult;
365
- DispatchResultOf: DispatchResultOf;
366
- DispatchResultTo198: DispatchResultTo198;
367
- DisputeLocation: DisputeLocation;
368
- DisputeProof: DisputeProof;
369
- DisputeResult: DisputeResult;
370
- DisputeState: DisputeState;
371
- DisputeStatement: DisputeStatement;
372
- DisputeStatementSet: DisputeStatementSet;
373
- DisputesTimeSlot: DisputesTimeSlot;
374
- DoubleEncodedCall: DoubleEncodedCall;
375
- DoubleVoteReport: DoubleVoteReport;
376
- DownwardMessage: DownwardMessage;
377
- EcdsaSignature: EcdsaSignature;
378
- Ed25519Signature: Ed25519Signature;
379
- EIP1559Transaction: EIP1559Transaction;
380
- EIP2930Transaction: EIP2930Transaction;
381
- ElectionCompute: ElectionCompute;
382
- ElectionPhase: ElectionPhase;
383
- ElectionResult: ElectionResult;
384
- ElectionScore: ElectionScore;
385
- ElectionSize: ElectionSize;
386
- ElectionStatus: ElectionStatus;
387
- EncodedFinalityProofs: EncodedFinalityProofs;
388
- EncodedJustification: EncodedJustification;
389
- Epoch: Epoch;
390
- EpochAuthorship: EpochAuthorship;
391
- Era: Era;
392
- EraIndex: EraIndex;
393
- EraPoints: EraPoints;
394
- EraRewardPoints: EraRewardPoints;
395
- EraRewards: EraRewards;
396
- ErrorMetadataLatest: ErrorMetadataLatest;
397
- ErrorMetadataV10: ErrorMetadataV10;
398
- ErrorMetadataV11: ErrorMetadataV11;
399
- ErrorMetadataV12: ErrorMetadataV12;
400
- ErrorMetadataV13: ErrorMetadataV13;
401
- ErrorMetadataV14: ErrorMetadataV14;
402
- ErrorMetadataV9: ErrorMetadataV9;
403
- EthAccessList: EthAccessList;
404
- EthAccessListItem: EthAccessListItem;
405
- EthAccount: EthAccount;
406
- EthAddress: EthAddress;
407
- EthBlock: EthBlock;
408
- EthBloom: EthBloom;
409
- EthCallRequest: EthCallRequest;
410
- EthereumAccountId: EthereumAccountId;
411
- EthereumAddress: EthereumAddress;
412
- EthereumLookupSource: EthereumLookupSource;
413
- EthereumSignature: EthereumSignature;
414
- EthFeeHistory: EthFeeHistory;
415
- EthFilter: EthFilter;
416
- EthFilterAddress: EthFilterAddress;
417
- EthFilterChanges: EthFilterChanges;
418
- EthFilterTopic: EthFilterTopic;
419
- EthFilterTopicEntry: EthFilterTopicEntry;
420
- EthFilterTopicInner: EthFilterTopicInner;
421
- EthHeader: EthHeader;
422
- EthLog: EthLog;
423
- EthReceipt: EthReceipt;
424
- EthReceiptV0: EthReceiptV0;
425
- EthReceiptV3: EthReceiptV3;
426
- EthRichBlock: EthRichBlock;
427
- EthRichHeader: EthRichHeader;
428
- EthStorageProof: EthStorageProof;
429
- EthSubKind: EthSubKind;
430
- EthSubParams: EthSubParams;
431
- EthSubResult: EthSubResult;
432
- EthSyncInfo: EthSyncInfo;
433
- EthSyncStatus: EthSyncStatus;
434
- EthTransaction: EthTransaction;
435
- EthTransactionAction: EthTransactionAction;
436
- EthTransactionCondition: EthTransactionCondition;
437
- EthTransactionRequest: EthTransactionRequest;
438
- EthTransactionSignature: EthTransactionSignature;
439
- EthTransactionStatus: EthTransactionStatus;
440
- EthWork: EthWork;
441
- Event: Event;
442
- EventId: EventId;
443
- EventIndex: EventIndex;
444
- EventMetadataLatest: EventMetadataLatest;
445
- EventMetadataV10: EventMetadataV10;
446
- EventMetadataV11: EventMetadataV11;
447
- EventMetadataV12: EventMetadataV12;
448
- EventMetadataV13: EventMetadataV13;
449
- EventMetadataV14: EventMetadataV14;
450
- EventMetadataV9: EventMetadataV9;
451
- EventRecord: EventRecord;
452
- EvmAccount: EvmAccount;
453
- EvmCallInfo: EvmCallInfo;
454
- EvmCallInfoV2: EvmCallInfoV2;
455
- EvmCreateInfo: EvmCreateInfo;
456
- EvmCreateInfoV2: EvmCreateInfoV2;
457
- EvmLog: EvmLog;
458
- EvmVicinity: EvmVicinity;
459
- EvmWeightInfo: EvmWeightInfo;
460
- ExecReturnValue: ExecReturnValue;
461
- ExecutorParam: ExecutorParam;
462
- ExecutorParams: ExecutorParams;
463
- ExecutorParamsHash: ExecutorParamsHash;
464
- ExitError: ExitError;
465
- ExitFatal: ExitFatal;
466
- ExitReason: ExitReason;
467
- ExitRevert: ExitRevert;
468
- ExitSucceed: ExitSucceed;
469
- ExplicitDisputeStatement: ExplicitDisputeStatement;
470
- Exposure: Exposure;
471
- ExtendedBalance: ExtendedBalance;
472
- Extrinsic: Extrinsic;
473
- ExtrinsicEra: ExtrinsicEra;
474
- ExtrinsicInclusionMode: ExtrinsicInclusionMode;
475
- ExtrinsicMetadataLatest: ExtrinsicMetadataLatest;
476
- ExtrinsicMetadataV11: ExtrinsicMetadataV11;
477
- ExtrinsicMetadataV12: ExtrinsicMetadataV12;
478
- ExtrinsicMetadataV13: ExtrinsicMetadataV13;
479
- ExtrinsicMetadataV14: ExtrinsicMetadataV14;
480
- ExtrinsicMetadataV15: ExtrinsicMetadataV15;
481
- ExtrinsicOrHash: ExtrinsicOrHash;
482
- ExtrinsicPayload: ExtrinsicPayload;
483
- ExtrinsicPayloadUnknown: ExtrinsicPayloadUnknown;
484
- ExtrinsicPayloadV4: ExtrinsicPayloadV4;
485
- ExtrinsicSignature: ExtrinsicSignature;
486
- ExtrinsicSignatureV4: ExtrinsicSignatureV4;
487
- ExtrinsicStatus: ExtrinsicStatus;
488
- ExtrinsicsWeight: ExtrinsicsWeight;
489
- ExtrinsicUnknown: ExtrinsicUnknown;
490
- ExtrinsicV4: ExtrinsicV4;
491
- f32: f32;
492
- F32: F32;
493
- f64: f64;
494
- F64: F64;
495
- FeeDetails: FeeDetails;
496
- Fixed128: Fixed128;
497
- Fixed64: Fixed64;
498
- FixedI128: FixedI128;
499
- FixedI64: FixedI64;
500
- FixedU128: FixedU128;
501
- FixedU64: FixedU64;
502
- Forcing: Forcing;
503
- ForkTreePendingChange: ForkTreePendingChange;
504
- ForkTreePendingChangeNode: ForkTreePendingChangeNode;
505
- FullIdentification: FullIdentification;
506
- FunctionArgumentMetadataLatest: FunctionArgumentMetadataLatest;
507
- FunctionArgumentMetadataV10: FunctionArgumentMetadataV10;
508
- FunctionArgumentMetadataV11: FunctionArgumentMetadataV11;
509
- FunctionArgumentMetadataV12: FunctionArgumentMetadataV12;
510
- FunctionArgumentMetadataV13: FunctionArgumentMetadataV13;
511
- FunctionArgumentMetadataV14: FunctionArgumentMetadataV14;
512
- FunctionArgumentMetadataV9: FunctionArgumentMetadataV9;
513
- FunctionMetadataLatest: FunctionMetadataLatest;
514
- FunctionMetadataV10: FunctionMetadataV10;
515
- FunctionMetadataV11: FunctionMetadataV11;
516
- FunctionMetadataV12: FunctionMetadataV12;
517
- FunctionMetadataV13: FunctionMetadataV13;
518
- FunctionMetadataV14: FunctionMetadataV14;
519
- FunctionMetadataV9: FunctionMetadataV9;
520
- FundIndex: FundIndex;
521
- FundInfo: FundInfo;
522
- Fungibility: Fungibility;
523
- FungibilityV0: FungibilityV0;
524
- FungibilityV1: FungibilityV1;
525
- FungibilityV2: FungibilityV2;
526
- FungiblesAccessError: FungiblesAccessError;
527
- Gas: Gas;
528
- GenesisBuildErr: GenesisBuildErr;
529
- GiltBid: GiltBid;
530
- GlobalValidationData: GlobalValidationData;
531
- GlobalValidationSchedule: GlobalValidationSchedule;
532
- GrandpaCommit: GrandpaCommit;
533
- GrandpaEquivocation: GrandpaEquivocation;
534
- GrandpaEquivocationProof: GrandpaEquivocationProof;
535
- GrandpaEquivocationValue: GrandpaEquivocationValue;
536
- GrandpaJustification: GrandpaJustification;
537
- GrandpaPrecommit: GrandpaPrecommit;
538
- GrandpaPrevote: GrandpaPrevote;
539
- GrandpaSignedPrecommit: GrandpaSignedPrecommit;
540
- GroupIndex: GroupIndex;
541
- GroupRotationInfo: GroupRotationInfo;
542
- H1024: H1024;
543
- H128: H128;
544
- H160: H160;
545
- H2048: H2048;
546
- H256: H256;
547
- H32: H32;
548
- H512: H512;
549
- H64: H64;
550
- Hash: Hash;
551
- HeadData: HeadData;
552
- Header: Header;
553
- HeaderPartial: HeaderPartial;
554
- Health: Health;
555
- Heartbeat: Heartbeat;
556
- HeartbeatTo244: HeartbeatTo244;
557
- HostConfiguration: HostConfiguration;
558
- HostFnWeights: HostFnWeights;
559
- HostFnWeightsTo264: HostFnWeightsTo264;
560
- HrmpChannel: HrmpChannel;
561
- HrmpChannelId: HrmpChannelId;
562
- HrmpOpenChannelRequest: HrmpOpenChannelRequest;
563
- i128: i128;
564
- I128: I128;
565
- i16: i16;
566
- I16: I16;
567
- i256: i256;
568
- I256: I256;
569
- i32: i32;
570
- I32: I32;
571
- I32F32: I32F32;
572
- i64: i64;
573
- I64: I64;
574
- i8: i8;
575
- I8: I8;
576
- IdentificationTuple: IdentificationTuple;
577
- IdentityFields: IdentityFields;
578
- IdentityInfo: IdentityInfo;
579
- IdentityInfoAdditional: IdentityInfoAdditional;
580
- IdentityInfoTo198: IdentityInfoTo198;
581
- IdentityJudgement: IdentityJudgement;
582
- ImmortalEra: ImmortalEra;
583
- ImportedAux: ImportedAux;
584
- InboundDownwardMessage: InboundDownwardMessage;
585
- InboundHrmpLimitations: InboundHrmpLimitations;
586
- InboundHrmpMessage: InboundHrmpMessage;
587
- InboundHrmpMessages: InboundHrmpMessages;
588
- InboundLaneData: InboundLaneData;
589
- InboundRelayer: InboundRelayer;
590
- InboundStatus: InboundStatus;
591
- IncludedBlocks: IncludedBlocks;
592
- InclusionFee: InclusionFee;
593
- IncomingParachain: IncomingParachain;
594
- IncomingParachainDeploy: IncomingParachainDeploy;
595
- IncomingParachainFixed: IncomingParachainFixed;
596
- Index: Index;
597
- IndicesLookupSource: IndicesLookupSource;
598
- IndividualExposure: IndividualExposure;
599
- InherentData: InherentData;
600
- InherentIdentifier: InherentIdentifier;
601
- InitializationData: InitializationData;
602
- InstanceDetails: InstanceDetails;
603
- InstanceId: InstanceId;
604
- InstanceMetadata: InstanceMetadata;
605
- InstantiateRequest: InstantiateRequest;
606
- InstantiateRequestV1: InstantiateRequestV1;
607
- InstantiateRequestV2: InstantiateRequestV2;
608
- InstantiateReturnValue: InstantiateReturnValue;
609
- InstantiateReturnValueOk: InstantiateReturnValueOk;
610
- InstantiateReturnValueTo267: InstantiateReturnValueTo267;
611
- InstructionV2: InstructionV2;
612
- InstructionWeights: InstructionWeights;
613
- InteriorMultiLocation: InteriorMultiLocation;
614
- InvalidDisputeStatementKind: InvalidDisputeStatementKind;
615
- InvalidTransaction: InvalidTransaction;
616
- isize: isize;
617
- ISize: ISize;
618
- Json: Json;
619
- Junction: Junction;
620
- Junctions: Junctions;
621
- JunctionsV1: JunctionsV1;
622
- JunctionsV2: JunctionsV2;
623
- JunctionV0: JunctionV0;
624
- JunctionV1: JunctionV1;
625
- JunctionV2: JunctionV2;
626
- Justification: Justification;
627
- JustificationNotification: JustificationNotification;
628
- Justifications: Justifications;
629
- Key: Key;
630
- KeyOwnerProof: KeyOwnerProof;
631
- Keys: Keys;
632
- KeyType: KeyType;
633
- KeyTypeId: KeyTypeId;
634
- KeyValue: KeyValue;
635
- KeyValueOption: KeyValueOption;
636
- Kind: Kind;
637
- LaneId: LaneId;
638
- LastContribution: LastContribution;
639
- LastRuntimeUpgradeInfo: LastRuntimeUpgradeInfo;
640
- LeasePeriod: LeasePeriod;
641
- LeasePeriodOf: LeasePeriodOf;
642
- LegacyTransaction: LegacyTransaction;
643
- Limits: Limits;
644
- LimitsTo264: LimitsTo264;
645
- LocalValidationData: LocalValidationData;
646
- LockIdentifier: LockIdentifier;
647
- LookupSource: LookupSource;
648
- LookupTarget: LookupTarget;
649
- LotteryConfig: LotteryConfig;
650
- MaybeRandomness: MaybeRandomness;
651
- MaybeVrf: MaybeVrf;
652
- MemberCount: MemberCount;
653
- MembershipProof: MembershipProof;
654
- MessageData: MessageData;
655
- MessageId: MessageId;
656
- MessageIngestionType: MessageIngestionType;
657
- MessageKey: MessageKey;
658
- MessageNonce: MessageNonce;
659
- MessageQueueChain: MessageQueueChain;
660
- MessagesDeliveryProofOf: MessagesDeliveryProofOf;
661
- MessagesProofOf: MessagesProofOf;
662
- MessagingStateSnapshot: MessagingStateSnapshot;
663
- MessagingStateSnapshotEgressEntry: MessagingStateSnapshotEgressEntry;
664
- MetadataAll: MetadataAll;
665
- MetadataLatest: MetadataLatest;
666
- MetadataV10: MetadataV10;
667
- MetadataV11: MetadataV11;
668
- MetadataV12: MetadataV12;
669
- MetadataV13: MetadataV13;
670
- MetadataV14: MetadataV14;
671
- MetadataV15: MetadataV15;
672
- MetadataV9: MetadataV9;
673
- MigrationStatusResult: MigrationStatusResult;
674
- Mixnode: Mixnode;
675
- MixnodesErr: MixnodesErr;
676
- MmrBatchProof: MmrBatchProof;
677
- MmrEncodableOpaqueLeaf: MmrEncodableOpaqueLeaf;
678
- MmrError: MmrError;
679
- MmrHash: MmrHash;
680
- MmrLeafBatchProof: MmrLeafBatchProof;
681
- MmrLeafIndex: MmrLeafIndex;
682
- MmrLeafProof: MmrLeafProof;
683
- MmrNodeIndex: MmrNodeIndex;
684
- MmrProof: MmrProof;
685
- MmrRootHash: MmrRootHash;
686
- ModuleConstantMetadataV10: ModuleConstantMetadataV10;
687
- ModuleConstantMetadataV11: ModuleConstantMetadataV11;
688
- ModuleConstantMetadataV12: ModuleConstantMetadataV12;
689
- ModuleConstantMetadataV13: ModuleConstantMetadataV13;
690
- ModuleConstantMetadataV9: ModuleConstantMetadataV9;
691
- ModuleId: ModuleId;
692
- ModuleMetadataV10: ModuleMetadataV10;
693
- ModuleMetadataV11: ModuleMetadataV11;
694
- ModuleMetadataV12: ModuleMetadataV12;
695
- ModuleMetadataV13: ModuleMetadataV13;
696
- ModuleMetadataV9: ModuleMetadataV9;
697
- Moment: Moment;
698
- MomentOf: MomentOf;
699
- MoreAttestations: MoreAttestations;
700
- MortalEra: MortalEra;
701
- MultiAddress: MultiAddress;
702
- MultiAsset: MultiAsset;
703
- MultiAssetFilter: MultiAssetFilter;
704
- MultiAssetFilterV1: MultiAssetFilterV1;
705
- MultiAssetFilterV2: MultiAssetFilterV2;
706
- MultiAssets: MultiAssets;
707
- MultiAssetsV1: MultiAssetsV1;
708
- MultiAssetsV2: MultiAssetsV2;
709
- MultiAssetV0: MultiAssetV0;
710
- MultiAssetV1: MultiAssetV1;
711
- MultiAssetV2: MultiAssetV2;
712
- MultiDisputeStatementSet: MultiDisputeStatementSet;
713
- MultiLocation: MultiLocation;
714
- MultiLocationV0: MultiLocationV0;
715
- MultiLocationV1: MultiLocationV1;
716
- MultiLocationV2: MultiLocationV2;
717
- Multiplier: Multiplier;
718
- Multisig: Multisig;
719
- MultiSignature: MultiSignature;
720
- MultiSigner: MultiSigner;
721
- NetworkId: NetworkId;
722
- NetworkState: NetworkState;
723
- NetworkStatePeerset: NetworkStatePeerset;
724
- NetworkStatePeersetInfo: NetworkStatePeersetInfo;
725
- NewBidder: NewBidder;
726
- NextAuthority: NextAuthority;
727
- NextConfigDescriptor: NextConfigDescriptor;
728
- NextConfigDescriptorV1: NextConfigDescriptorV1;
729
- NftCollectionId: NftCollectionId;
730
- NftItemId: NftItemId;
731
- NodeFeatures: NodeFeatures;
732
- NodeRole: NodeRole;
733
- Nominations: Nominations;
734
- NominatorIndex: NominatorIndex;
735
- NominatorIndexCompact: NominatorIndexCompact;
736
- NotConnectedPeer: NotConnectedPeer;
737
- NpApiError: NpApiError;
738
- NpPoolId: NpPoolId;
739
- Null: Null;
740
- OccupiedCore: OccupiedCore;
741
- OccupiedCoreAssumption: OccupiedCoreAssumption;
742
- OffchainAccuracy: OffchainAccuracy;
743
- OffchainAccuracyCompact: OffchainAccuracyCompact;
744
- OffenceDetails: OffenceDetails;
745
- Offender: Offender;
746
- OldV1SessionInfo: OldV1SessionInfo;
747
- OpaqueCall: OpaqueCall;
748
- OpaqueKeyOwnershipProof: OpaqueKeyOwnershipProof;
749
- OpaqueMetadata: OpaqueMetadata;
750
- OpaqueMultiaddr: OpaqueMultiaddr;
751
- OpaqueNetworkState: OpaqueNetworkState;
752
- OpaquePeerId: OpaquePeerId;
753
- OpaqueTimeSlot: OpaqueTimeSlot;
754
- OpenTip: OpenTip;
755
- OpenTipFinderTo225: OpenTipFinderTo225;
756
- OpenTipTip: OpenTipTip;
757
- OpenTipTo225: OpenTipTo225;
758
- OperatingMode: OperatingMode;
759
- OptionBool: OptionBool;
760
- Origin: Origin;
761
- OriginCaller: OriginCaller;
762
- OriginKindV0: OriginKindV0;
763
- OriginKindV1: OriginKindV1;
764
- OriginKindV2: OriginKindV2;
765
- OutboundHrmpChannelLimitations: OutboundHrmpChannelLimitations;
766
- OutboundHrmpMessage: OutboundHrmpMessage;
767
- OutboundLaneData: OutboundLaneData;
768
- OutboundMessageFee: OutboundMessageFee;
769
- OutboundPayload: OutboundPayload;
770
- OutboundStatus: OutboundStatus;
771
- Outcome: Outcome;
772
- OuterEnums15: OuterEnums15;
773
- OverweightIndex: OverweightIndex;
774
- Owner: Owner;
775
- PageCounter: PageCounter;
776
- PageIndexData: PageIndexData;
777
- PalletCallMetadataLatest: PalletCallMetadataLatest;
778
- PalletCallMetadataV14: PalletCallMetadataV14;
779
- PalletConstantMetadataLatest: PalletConstantMetadataLatest;
780
- PalletConstantMetadataV14: PalletConstantMetadataV14;
781
- PalletErrorMetadataLatest: PalletErrorMetadataLatest;
782
- PalletErrorMetadataV14: PalletErrorMetadataV14;
783
- PalletEventMetadataLatest: PalletEventMetadataLatest;
784
- PalletEventMetadataV14: PalletEventMetadataV14;
785
- PalletId: PalletId;
786
- PalletMetadataLatest: PalletMetadataLatest;
787
- PalletMetadataV14: PalletMetadataV14;
788
- PalletMetadataV15: PalletMetadataV15;
789
- PalletsOrigin: PalletsOrigin;
790
- PalletStorageMetadataLatest: PalletStorageMetadataLatest;
791
- PalletStorageMetadataV14: PalletStorageMetadataV14;
792
- PalletVersion: PalletVersion;
793
- ParachainDispatchOrigin: ParachainDispatchOrigin;
794
- ParachainInherentData: ParachainInherentData;
795
- ParachainProposal: ParachainProposal;
796
- ParachainsInherentData: ParachainsInherentData;
797
- ParaGenesisArgs: ParaGenesisArgs;
798
- ParaId: ParaId;
799
- ParaInfo: ParaInfo;
800
- ParaLifecycle: ParaLifecycle;
801
- Parameter: Parameter;
802
- ParaPastCodeMeta: ParaPastCodeMeta;
803
- ParaScheduling: ParaScheduling;
804
- ParathreadClaim: ParathreadClaim;
805
- ParathreadClaimQueue: ParathreadClaimQueue;
806
- ParathreadEntry: ParathreadEntry;
807
- ParaValidatorIndex: ParaValidatorIndex;
808
- Pays: Pays;
809
- Peer: Peer;
810
- PeerEndpoint: PeerEndpoint;
811
- PeerEndpointAddr: PeerEndpointAddr;
812
- PeerInfo: PeerInfo;
813
- PeerPing: PeerPing;
814
- PendingChange: PendingChange;
815
- PendingPause: PendingPause;
816
- PendingResume: PendingResume;
817
- PendingSlashes: PendingSlashes;
818
- Perbill: Perbill;
819
- Percent: Percent;
820
- PerDispatchClassU32: PerDispatchClassU32;
821
- PerDispatchClassWeight: PerDispatchClassWeight;
822
- PerDispatchClassWeightsPerClass: PerDispatchClassWeightsPerClass;
823
- Period: Period;
824
- Permill: Permill;
825
- PermissionLatest: PermissionLatest;
826
- PermissionsV1: PermissionsV1;
827
- PermissionVersions: PermissionVersions;
828
- Perquintill: Perquintill;
829
- PersistedValidationData: PersistedValidationData;
830
- PerU16: PerU16;
831
- Phantom: Phantom;
832
- PhantomData: PhantomData;
833
- Phase: Phase;
834
- PhragmenScore: PhragmenScore;
835
- Points: Points;
836
- PortableType: PortableType;
837
- PortableTypeV14: PortableTypeV14;
838
- Precommits: Precommits;
839
- PrefabWasmModule: PrefabWasmModule;
840
- PrefixedStorageKey: PrefixedStorageKey;
841
- PreimageStatus: PreimageStatus;
842
- PreimageStatusAvailable: PreimageStatusAvailable;
843
- PreRuntime: PreRuntime;
844
- Prevotes: Prevotes;
845
- Priority: Priority;
846
- PriorLock: PriorLock;
847
- PropIndex: PropIndex;
848
- Proposal: Proposal;
849
- ProposalIndex: ProposalIndex;
850
- ProxyAnnouncement: ProxyAnnouncement;
851
- ProxyDefinition: ProxyDefinition;
852
- ProxyState: ProxyState;
853
- ProxyType: ProxyType;
854
- PvfCheckStatement: PvfCheckStatement;
855
- PvfExecTimeoutKind: PvfExecTimeoutKind;
856
- PvfPrepTimeoutKind: PvfPrepTimeoutKind;
857
- QueryId: QueryId;
858
- QueryStatus: QueryStatus;
859
- QueueConfigData: QueueConfigData;
860
- QueuedParathread: QueuedParathread;
861
- Randomness: Randomness;
862
- Raw: Raw;
863
- RawAuraPreDigest: RawAuraPreDigest;
864
- RawBabePreDigest: RawBabePreDigest;
865
- RawBabePreDigestCompat: RawBabePreDigestCompat;
866
- RawBabePreDigestPrimary: RawBabePreDigestPrimary;
867
- RawBabePreDigestPrimaryTo159: RawBabePreDigestPrimaryTo159;
868
- RawBabePreDigestSecondaryPlain: RawBabePreDigestSecondaryPlain;
869
- RawBabePreDigestSecondaryTo159: RawBabePreDigestSecondaryTo159;
870
- RawBabePreDigestSecondaryVRF: RawBabePreDigestSecondaryVRF;
871
- RawBabePreDigestTo159: RawBabePreDigestTo159;
872
- RawOrigin: RawOrigin;
873
- RawSolution: RawSolution;
874
- RawSolutionTo265: RawSolutionTo265;
875
- RawSolutionWith16: RawSolutionWith16;
876
- RawSolutionWith24: RawSolutionWith24;
877
- RawVRFOutput: RawVRFOutput;
878
- ReadProof: ReadProof;
879
- ReadySolution: ReadySolution;
880
- Reasons: Reasons;
881
- RecoveryConfig: RecoveryConfig;
882
- RefCount: RefCount;
883
- RefCountTo259: RefCountTo259;
884
- ReferendumIndex: ReferendumIndex;
885
- ReferendumInfo: ReferendumInfo;
886
- ReferendumInfoFinished: ReferendumInfoFinished;
887
- ReferendumInfoTo239: ReferendumInfoTo239;
888
- ReferendumStatus: ReferendumStatus;
889
- RegisteredParachainInfo: RegisteredParachainInfo;
890
- RegistrarIndex: RegistrarIndex;
891
- RegistrarInfo: RegistrarInfo;
892
- Registration: Registration;
893
- RegistrationJudgement: RegistrationJudgement;
894
- RegistrationTo198: RegistrationTo198;
895
- RelayBlockNumber: RelayBlockNumber;
896
- RelayChainBlockNumber: RelayChainBlockNumber;
897
- RelayChainHash: RelayChainHash;
898
- RelayerId: RelayerId;
899
- RelayHash: RelayHash;
900
- Releases: Releases;
901
- Remark: Remark;
902
- Renouncing: Renouncing;
903
- RentProjection: RentProjection;
904
- ReplacementTimes: ReplacementTimes;
905
- ReportedRoundStates: ReportedRoundStates;
906
- Reporter: Reporter;
907
- ReportIdOf: ReportIdOf;
908
- ReserveData: ReserveData;
909
- ReserveIdentifier: ReserveIdentifier;
910
- Response: Response;
911
- ResponseV0: ResponseV0;
912
- ResponseV1: ResponseV1;
913
- ResponseV2: ResponseV2;
914
- ResponseV2Error: ResponseV2Error;
915
- ResponseV2Result: ResponseV2Result;
916
- Retriable: Retriable;
917
- RewardDestination: RewardDestination;
918
- RewardPoint: RewardPoint;
919
- RoundSnapshot: RoundSnapshot;
920
- RoundState: RoundState;
921
- RpcMethods: RpcMethods;
922
- RuntimeApiMetadataLatest: RuntimeApiMetadataLatest;
923
- RuntimeApiMetadataV15: RuntimeApiMetadataV15;
924
- RuntimeApiMethodMetadataV15: RuntimeApiMethodMetadataV15;
925
- RuntimeApiMethodParamMetadataV15: RuntimeApiMethodParamMetadataV15;
926
- RuntimeCall: RuntimeCall;
927
- RuntimeDbWeight: RuntimeDbWeight;
928
- RuntimeDispatchInfo: RuntimeDispatchInfo;
929
- RuntimeDispatchInfoV1: RuntimeDispatchInfoV1;
930
- RuntimeDispatchInfoV2: RuntimeDispatchInfoV2;
931
- RuntimeEvent: RuntimeEvent;
932
- RuntimeVersion: RuntimeVersion;
933
- RuntimeVersionApi: RuntimeVersionApi;
934
- RuntimeVersionPartial: RuntimeVersionPartial;
935
- RuntimeVersionPre3: RuntimeVersionPre3;
936
- RuntimeVersionPre4: RuntimeVersionPre4;
937
- Schedule: Schedule;
938
- Scheduled: Scheduled;
939
- ScheduledCore: ScheduledCore;
940
- ScheduledTo254: ScheduledTo254;
941
- SchedulePeriod: SchedulePeriod;
942
- SchedulePriority: SchedulePriority;
943
- ScheduleTo212: ScheduleTo212;
944
- ScheduleTo258: ScheduleTo258;
945
- ScheduleTo264: ScheduleTo264;
946
- Scheduling: Scheduling;
947
- ScrapedOnChainVotes: ScrapedOnChainVotes;
948
- Seal: Seal;
949
- SealV0: SealV0;
950
- SeatHolder: SeatHolder;
951
- SeedOf: SeedOf;
952
- ServiceQuality: ServiceQuality;
953
- SessionIndex: SessionIndex;
954
- SessionInfo: SessionInfo;
955
- SessionInfoValidatorGroup: SessionInfoValidatorGroup;
956
- SessionKeys1: SessionKeys1;
957
- SessionKeys10: SessionKeys10;
958
- SessionKeys10B: SessionKeys10B;
959
- SessionKeys2: SessionKeys2;
960
- SessionKeys3: SessionKeys3;
961
- SessionKeys4: SessionKeys4;
962
- SessionKeys5: SessionKeys5;
963
- SessionKeys6: SessionKeys6;
964
- SessionKeys6B: SessionKeys6B;
965
- SessionKeys7: SessionKeys7;
966
- SessionKeys7B: SessionKeys7B;
967
- SessionKeys8: SessionKeys8;
968
- SessionKeys8B: SessionKeys8B;
969
- SessionKeys9: SessionKeys9;
970
- SessionKeys9B: SessionKeys9B;
971
- SessionPhase: SessionPhase;
972
- SessionStatus: SessionStatus;
973
- SetId: SetId;
974
- SetIndex: SetIndex;
975
- Si0Field: Si0Field;
976
- Si0LookupTypeId: Si0LookupTypeId;
977
- Si0Path: Si0Path;
978
- Si0Type: Si0Type;
979
- Si0TypeDef: Si0TypeDef;
980
- Si0TypeDefArray: Si0TypeDefArray;
981
- Si0TypeDefBitSequence: Si0TypeDefBitSequence;
982
- Si0TypeDefCompact: Si0TypeDefCompact;
983
- Si0TypeDefComposite: Si0TypeDefComposite;
984
- Si0TypeDefPhantom: Si0TypeDefPhantom;
985
- Si0TypeDefPrimitive: Si0TypeDefPrimitive;
986
- Si0TypeDefSequence: Si0TypeDefSequence;
987
- Si0TypeDefTuple: Si0TypeDefTuple;
988
- Si0TypeDefVariant: Si0TypeDefVariant;
989
- Si0TypeParameter: Si0TypeParameter;
990
- Si0Variant: Si0Variant;
991
- Si1Field: Si1Field;
992
- Si1LookupTypeId: Si1LookupTypeId;
993
- Si1Path: Si1Path;
994
- Si1Type: Si1Type;
995
- Si1TypeDef: Si1TypeDef;
996
- Si1TypeDefArray: Si1TypeDefArray;
997
- Si1TypeDefBitSequence: Si1TypeDefBitSequence;
998
- Si1TypeDefCompact: Si1TypeDefCompact;
999
- Si1TypeDefComposite: Si1TypeDefComposite;
1000
- Si1TypeDefPrimitive: Si1TypeDefPrimitive;
1001
- Si1TypeDefSequence: Si1TypeDefSequence;
1002
- Si1TypeDefTuple: Si1TypeDefTuple;
1003
- Si1TypeDefVariant: Si1TypeDefVariant;
1004
- Si1TypeParameter: Si1TypeParameter;
1005
- Si1Variant: Si1Variant;
1006
- SiField: SiField;
1007
- Signature: Signature;
1008
- SignedAvailabilityBitfield: SignedAvailabilityBitfield;
1009
- SignedAvailabilityBitfields: SignedAvailabilityBitfields;
1010
- SignedBlock: SignedBlock;
1011
- SignedBlockWithJustification: SignedBlockWithJustification;
1012
- SignedBlockWithJustifications: SignedBlockWithJustifications;
1013
- SignedExtensionMetadataLatest: SignedExtensionMetadataLatest;
1014
- SignedExtensionMetadataV14: SignedExtensionMetadataV14;
1015
- SignedSubmission: SignedSubmission;
1016
- SignedSubmissionOf: SignedSubmissionOf;
1017
- SignedSubmissionTo276: SignedSubmissionTo276;
1018
- SignerPayload: SignerPayload;
1019
- SigningContext: SigningContext;
1020
- SiLookupTypeId: SiLookupTypeId;
1021
- SiPath: SiPath;
1022
- SiType: SiType;
1023
- SiTypeDef: SiTypeDef;
1024
- SiTypeDefArray: SiTypeDefArray;
1025
- SiTypeDefBitSequence: SiTypeDefBitSequence;
1026
- SiTypeDefCompact: SiTypeDefCompact;
1027
- SiTypeDefComposite: SiTypeDefComposite;
1028
- SiTypeDefPrimitive: SiTypeDefPrimitive;
1029
- SiTypeDefSequence: SiTypeDefSequence;
1030
- SiTypeDefTuple: SiTypeDefTuple;
1031
- SiTypeDefVariant: SiTypeDefVariant;
1032
- SiTypeParameter: SiTypeParameter;
1033
- SiVariant: SiVariant;
1034
- SlashingOffenceKind: SlashingOffenceKind;
1035
- SlashingSpans: SlashingSpans;
1036
- SlashingSpansTo204: SlashingSpansTo204;
1037
- SlashJournalEntry: SlashJournalEntry;
1038
- Slot: Slot;
1039
- SlotDuration: SlotDuration;
1040
- SlotNumber: SlotNumber;
1041
- SlotRange: SlotRange;
1042
- SlotRange10: SlotRange10;
1043
- SocietyJudgement: SocietyJudgement;
1044
- SocietyVote: SocietyVote;
1045
- SolutionOrSnapshotSize: SolutionOrSnapshotSize;
1046
- SolutionSupport: SolutionSupport;
1047
- SolutionSupports: SolutionSupports;
1048
- SpanIndex: SpanIndex;
1049
- SpanRecord: SpanRecord;
1050
- SpecVersion: SpecVersion;
1051
- Sr25519Signature: Sr25519Signature;
1052
- StakingLedger: StakingLedger;
1053
- StakingLedgerTo223: StakingLedgerTo223;
1054
- StakingLedgerTo240: StakingLedgerTo240;
1055
- Statement: Statement;
1056
- StatementKind: StatementKind;
1057
- StatementStoreInvalidStatement: StatementStoreInvalidStatement;
1058
- StatementStoreStatementSource: StatementStoreStatementSource;
1059
- StatementStoreValidStatement: StatementStoreValidStatement;
1060
- StorageChangeSet: StorageChangeSet;
1061
- StorageData: StorageData;
1062
- StorageDeposit: StorageDeposit;
1063
- StorageEntryMetadataLatest: StorageEntryMetadataLatest;
1064
- StorageEntryMetadataV10: StorageEntryMetadataV10;
1065
- StorageEntryMetadataV11: StorageEntryMetadataV11;
1066
- StorageEntryMetadataV12: StorageEntryMetadataV12;
1067
- StorageEntryMetadataV13: StorageEntryMetadataV13;
1068
- StorageEntryMetadataV14: StorageEntryMetadataV14;
1069
- StorageEntryMetadataV9: StorageEntryMetadataV9;
1070
- StorageEntryModifierLatest: StorageEntryModifierLatest;
1071
- StorageEntryModifierV10: StorageEntryModifierV10;
1072
- StorageEntryModifierV11: StorageEntryModifierV11;
1073
- StorageEntryModifierV12: StorageEntryModifierV12;
1074
- StorageEntryModifierV13: StorageEntryModifierV13;
1075
- StorageEntryModifierV14: StorageEntryModifierV14;
1076
- StorageEntryModifierV9: StorageEntryModifierV9;
1077
- StorageEntryTypeLatest: StorageEntryTypeLatest;
1078
- StorageEntryTypeV10: StorageEntryTypeV10;
1079
- StorageEntryTypeV11: StorageEntryTypeV11;
1080
- StorageEntryTypeV12: StorageEntryTypeV12;
1081
- StorageEntryTypeV13: StorageEntryTypeV13;
1082
- StorageEntryTypeV14: StorageEntryTypeV14;
1083
- StorageEntryTypeV9: StorageEntryTypeV9;
1084
- StorageHasher: StorageHasher;
1085
- StorageHasherV10: StorageHasherV10;
1086
- StorageHasherV11: StorageHasherV11;
1087
- StorageHasherV12: StorageHasherV12;
1088
- StorageHasherV13: StorageHasherV13;
1089
- StorageHasherV14: StorageHasherV14;
1090
- StorageHasherV9: StorageHasherV9;
1091
- StorageInfo: StorageInfo;
1092
- StorageKey: StorageKey;
1093
- StorageKind: StorageKind;
1094
- StorageMetadataV10: StorageMetadataV10;
1095
- StorageMetadataV11: StorageMetadataV11;
1096
- StorageMetadataV12: StorageMetadataV12;
1097
- StorageMetadataV13: StorageMetadataV13;
1098
- StorageMetadataV9: StorageMetadataV9;
1099
- StorageProof: StorageProof;
1100
- StoredPendingChange: StoredPendingChange;
1101
- StoredState: StoredState;
1102
- StrikeCount: StrikeCount;
1103
- SubId: SubId;
1104
- SubmissionIndicesOf: SubmissionIndicesOf;
1105
- Supports: Supports;
1106
- SyncState: SyncState;
1107
- SystemInherentData: SystemInherentData;
1108
- SystemOrigin: SystemOrigin;
1109
- Tally: Tally;
1110
- TaskAddress: TaskAddress;
1111
- TAssetBalance: TAssetBalance;
1112
- TAssetConversion: TAssetConversion;
1113
- TAssetDepositBalance: TAssetDepositBalance;
1114
- Text: Text;
1115
- Timepoint: Timepoint;
1116
- TokenError: TokenError;
1117
- TombstoneContractInfo: TombstoneContractInfo;
1118
- TraceBlockResponse: TraceBlockResponse;
1119
- TraceError: TraceError;
1120
- TransactionalError: TransactionalError;
1121
- TransactionInfo: TransactionInfo;
1122
- TransactionLongevity: TransactionLongevity;
1123
- TransactionPriority: TransactionPriority;
1124
- TransactionSource: TransactionSource;
1125
- TransactionStorageProof: TransactionStorageProof;
1126
- TransactionTag: TransactionTag;
1127
- TransactionV0: TransactionV0;
1128
- TransactionV1: TransactionV1;
1129
- TransactionV2: TransactionV2;
1130
- TransactionValidity: TransactionValidity;
1131
- TransactionValidityError: TransactionValidityError;
1132
- TransientValidationData: TransientValidationData;
1133
- TreasuryProposal: TreasuryProposal;
1134
- TrieId: TrieId;
1135
- TrieIndex: TrieIndex;
1136
- Type: Type;
1137
- u128: u128;
1138
- U128: U128;
1139
- u16: u16;
1140
- U16: U16;
1141
- u256: u256;
1142
- U256: U256;
1143
- u32: u32;
1144
- U32: U32;
1145
- U32F32: U32F32;
1146
- u64: u64;
1147
- U64: U64;
1148
- u8: u8;
1149
- U8: U8;
1150
- UnappliedSlash: UnappliedSlash;
1151
- UnappliedSlashOther: UnappliedSlashOther;
1152
- UncleEntryItem: UncleEntryItem;
1153
- UnknownTransaction: UnknownTransaction;
1154
- UnlockChunk: UnlockChunk;
1155
- UnrewardedRelayer: UnrewardedRelayer;
1156
- UnrewardedRelayersState: UnrewardedRelayersState;
1157
- UpgradeGoAhead: UpgradeGoAhead;
1158
- UpgradeRestriction: UpgradeRestriction;
1159
- UpwardMessage: UpwardMessage;
1160
- usize: usize;
1161
- USize: USize;
1162
- ValidationCode: ValidationCode;
1163
- ValidationCodeHash: ValidationCodeHash;
1164
- ValidationData: ValidationData;
1165
- ValidationDataType: ValidationDataType;
1166
- ValidationFunctionParams: ValidationFunctionParams;
1167
- ValidatorCount: ValidatorCount;
1168
- ValidatorId: ValidatorId;
1169
- ValidatorIdOf: ValidatorIdOf;
1170
- ValidatorIndex: ValidatorIndex;
1171
- ValidatorIndexCompact: ValidatorIndexCompact;
1172
- ValidatorPrefs: ValidatorPrefs;
1173
- ValidatorPrefsTo145: ValidatorPrefsTo145;
1174
- ValidatorPrefsTo196: ValidatorPrefsTo196;
1175
- ValidatorPrefsWithBlocked: ValidatorPrefsWithBlocked;
1176
- ValidatorPrefsWithCommission: ValidatorPrefsWithCommission;
1177
- ValidatorSet: ValidatorSet;
1178
- ValidatorSetId: ValidatorSetId;
1179
- ValidatorSignature: ValidatorSignature;
1180
- ValidDisputeStatementKind: ValidDisputeStatementKind;
1181
- ValidityAttestation: ValidityAttestation;
1182
- ValidTransaction: ValidTransaction;
1183
- VecInboundHrmpMessage: VecInboundHrmpMessage;
1184
- VersionedMultiAsset: VersionedMultiAsset;
1185
- VersionedMultiAssets: VersionedMultiAssets;
1186
- VersionedMultiLocation: VersionedMultiLocation;
1187
- VersionedResponse: VersionedResponse;
1188
- VersionedXcm: VersionedXcm;
1189
- VersionMigrationStage: VersionMigrationStage;
1190
- VestingInfo: VestingInfo;
1191
- VestingSchedule: VestingSchedule;
1192
- Vote: Vote;
1193
- VoteIndex: VoteIndex;
1194
- Voter: Voter;
1195
- VoterInfo: VoterInfo;
1196
- Votes: Votes;
1197
- VotesTo230: VotesTo230;
1198
- VoteThreshold: VoteThreshold;
1199
- VoteWeight: VoteWeight;
1200
- Voting: Voting;
1201
- VotingDelegating: VotingDelegating;
1202
- VotingDirect: VotingDirect;
1203
- VotingDirectVote: VotingDirectVote;
1204
- VouchingStatus: VouchingStatus;
1205
- VrfData: VrfData;
1206
- VrfOutput: VrfOutput;
1207
- VrfProof: VrfProof;
1208
- Weight: Weight;
1209
- WeightLimitV2: WeightLimitV2;
1210
- WeightMultiplier: WeightMultiplier;
1211
- WeightPerClass: WeightPerClass;
1212
- WeightToFeeCoefficient: WeightToFeeCoefficient;
1213
- WeightV0: WeightV0;
1214
- WeightV1: WeightV1;
1215
- WeightV2: WeightV2;
1216
- WildFungibility: WildFungibility;
1217
- WildFungibilityV0: WildFungibilityV0;
1218
- WildFungibilityV1: WildFungibilityV1;
1219
- WildFungibilityV2: WildFungibilityV2;
1220
- WildMultiAsset: WildMultiAsset;
1221
- WildMultiAssetV1: WildMultiAssetV1;
1222
- WildMultiAssetV2: WildMultiAssetV2;
1223
- WinnersData: WinnersData;
1224
- WinnersData10: WinnersData10;
1225
- WinnersDataTuple: WinnersDataTuple;
1226
- WinnersDataTuple10: WinnersDataTuple10;
1227
- WinningData: WinningData;
1228
- WinningData10: WinningData10;
1229
- WinningDataEntry: WinningDataEntry;
1230
- WithdrawReasons: WithdrawReasons;
1231
- Xcm: Xcm;
1232
- XcmAssetId: XcmAssetId;
1233
- XcmError: XcmError;
1234
- XcmErrorV0: XcmErrorV0;
1235
- XcmErrorV1: XcmErrorV1;
1236
- XcmErrorV2: XcmErrorV2;
1237
- XcmOrder: XcmOrder;
1238
- XcmOrderV0: XcmOrderV0;
1239
- XcmOrderV1: XcmOrderV1;
1240
- XcmOrderV2: XcmOrderV2;
1241
- XcmOrigin: XcmOrigin;
1242
- XcmOriginKind: XcmOriginKind;
1243
- XcmpMessageFormat: XcmpMessageFormat;
1244
- XcmV0: XcmV0;
1245
- XcmV1: XcmV1;
1246
- XcmV2: XcmV2;
1247
- XcmVersion: XcmVersion;
1248
- }
1249
- }