diff --git a/crates/iota-benchmark/src/lib.rs b/crates/iota-benchmark/src/lib.rs index a0f931b019c..e4845c2715e 100644 --- a/crates/iota-benchmark/src/lib.rs +++ b/crates/iota-benchmark/src/lib.rs @@ -355,7 +355,7 @@ impl ValidatorProxy for LocalValidatorAggregatorProxy { let ticket = self .qd .submit_transaction( - iota_types::quorum_driver_types::ExecuteTransactionRequestV3 { + iota_types::quorum_driver_types::ExecuteTransactionRequestV1 { transaction: tx.clone(), include_events: true, include_input_objects: false, diff --git a/crates/iota-benchmark/tests/simtest.rs b/crates/iota-benchmark/tests/simtest.rs index 4804e0cf23a..f903d1db610 100644 --- a/crates/iota-benchmark/tests/simtest.rs +++ b/crates/iota-benchmark/tests/simtest.rs @@ -111,7 +111,7 @@ mod test { ..Default::default() }) .with_submit_delay_step_override_millis(3000) - .with_state_accumulator_v2_enabled_callback(Arc::new(|idx| idx % 2 == 0)) + .with_state_accumulator_callback(Arc::new(|idx| idx % 2 == 0)) .build() .await .into(); diff --git a/crates/iota-config/src/node.rs b/crates/iota-config/src/node.rs index 147e8b5d036..3821e0d4261 100644 --- a/crates/iota-config/src/node.rs +++ b/crates/iota-config/src/node.rs @@ -242,11 +242,6 @@ pub struct NodeConfig { #[serde(default)] pub execution_cache: ExecutionCacheConfig, - // step 1 in removing the old state accumulator - #[serde(skip)] - #[serde(default = "bool_true")] - pub state_accumulator_v2: bool, - #[serde(default = "bool_true")] pub enable_validator_tx_finalizer: bool, } diff --git a/crates/iota-core/src/authority.rs b/crates/iota-core/src/authority.rs index a0bf8f330f0..9542d7d6f70 100644 --- a/crates/iota-core/src/authority.rs +++ b/crates/iota-core/src/authority.rs @@ -65,7 +65,7 @@ use iota_types::{ TransactionEvents, VerifiedCertifiedTransactionEffects, VerifiedSignedTransactionEffects, }, error::{ExecutionError, IotaError, IotaResult, UserInputError}, - event::{Event, EventID, SystemEpochInfoEvent}, + event::{Event, EventID, SystemEpochInfoEventV1}, executable_transaction::VerifiedExecutableTransaction, execution_config_utils::to_binary_config, execution_status::ExecutionStatus, @@ -1395,7 +1395,7 @@ impl AuthorityState { ) .await?; - if let TransactionKind::AuthenticatorStateUpdate(auth_state) = + if let TransactionKind::AuthenticatorStateUpdateV1(auth_state) = certificate.data().transaction_data().kind() { if let Some(err) = &execution_error_opt { @@ -1459,25 +1459,6 @@ impl AuthorityState { let output_keys = inner_temporary_store.get_output_keys(effects); - // Only need to sign effects if we are a validator, and if the - // executed_in_epoch_table is not yet enabled. TODO: once - // executed_in_epoch_table is enabled everywhere, we can remove the code below - // entirely. - let should_sign_effects = - self.is_validator(epoch_store) && !epoch_store.executed_in_epoch_table_enabled(); - - let effects_sig = if should_sign_effects { - Some(AuthoritySignInfo::new( - epoch_store.epoch(), - effects, - Intent::iota_app(IntentScope::TransactionEffects), - self.name, - &*self.secret, - )) - } else { - None - }; - // index certificate let _ = self .post_process_one_tx(certificate, effects, &inner_temporary_store, epoch_store) @@ -1490,12 +1471,7 @@ impl AuthorityState { // The insertion to epoch_store is not atomic with the insertion to the // perpetual store. This is OK because we insert to the epoch store // first. And during lookups we always look up in the perpetual store first. - epoch_store.insert_tx_key_and_effects_signature( - &tx_key, - tx_digest, - &effects.digest(), - effects_sig.as_ref(), - )?; + epoch_store.insert_tx_key_and_digest(&tx_key, tx_digest)?; // Allow testing what happens if we crash here. fail_point_async!("crash"); @@ -2120,12 +2096,6 @@ impl AuthorityState { indexes .index_tx( cert.data().intent_message().value.sender(), - cert.data() - .intent_message() - .value - .input_objects()? - .iter() - .map(|o| o.object_id()), effects .all_changed_objects() .into_iter() @@ -4673,7 +4643,7 @@ impl AuthorityState { gas_cost_summary: &GasCostSummary, checkpoint: CheckpointSequenceNumber, epoch_start_timestamp_ms: CheckpointTimestamp, - ) -> anyhow::Result<(IotaSystemState, SystemEpochInfoEvent, TransactionEffects)> { + ) -> anyhow::Result<(IotaSystemState, SystemEpochInfoEventV1, TransactionEffects)> { let mut txns = Vec::new(); if let Some(tx) = self.create_authenticator_state_tx(epoch_store) { @@ -4808,14 +4778,14 @@ impl AuthorityState { self.prepare_certificate(&execution_guard, &executable_tx, input_objects, epoch_store)?; let system_obj = get_iota_system_state(&temporary_store.written) .expect("change epoch tx must write to system object"); - // Find the SystemEpochInfoEvent emitted by the advance_epoch transaction. + // Find the SystemEpochInfoEventV1 emitted by the advance_epoch transaction. let system_epoch_info_event = temporary_store .events .data .iter() .find(|event| event.is_system_epoch_info_event()) .expect("end of epoch tx must emit system epoch info event"); - let system_epoch_info_event = bcs::from_bytes::( + let system_epoch_info_event = bcs::from_bytes::( &system_epoch_info_event.contents, ) .expect("deserialization should succeed since we asserted that the event is of this type"); diff --git a/crates/iota-core/src/authority/authority_per_epoch_store.rs b/crates/iota-core/src/authority/authority_per_epoch_store.rs index f9ae9e10e98..75c501b40df 100644 --- a/crates/iota-core/src/authority/authority_per_epoch_store.rs +++ b/crates/iota-core/src/authority/authority_per_epoch_store.rs @@ -56,7 +56,7 @@ use iota_types::{ signature::GenericSignature, storage::{BackingPackageStore, GetSharedLocks, InputKey, ObjectStore}, transaction::{ - AuthenticatorStateUpdate, CertifiedTransaction, InputObjectKind, SenderSignedData, + AuthenticatorStateUpdateV1, CertifiedTransaction, InputObjectKind, SenderSignedData, Transaction, TransactionDataAPI, TransactionKey, TransactionKind, VerifiedCertificate, VerifiedSignedTransaction, VerifiedTransaction, }, @@ -89,14 +89,14 @@ use super::{ use crate::{ authority::{ AuthorityMetrics, ResolverWrapper, - epoch_start_configuration::{EpochFlag, EpochStartConfiguration}, + epoch_start_configuration::EpochStartConfiguration, shared_object_version_manager::{ AssignedTxAndVersions, ConsensusSharedObjVerAssignment, SharedObjVerManager, }, }, checkpoints::{ BuilderCheckpointSummary, CheckpointHeight, CheckpointServiceNotify, EpochStats, - PendingCheckpointInfo, PendingCheckpointV2, PendingCheckpointV2Contents, + PendingCheckpoint, PendingCheckpointContentsV1, PendingCheckpointInfo, }, consensus_handler::{ ConsensusCommitInfo, SequencedConsensusTransaction, SequencedConsensusTransactionKey, @@ -379,8 +379,6 @@ pub struct AuthorityPerEpochStore { pub(crate) metrics: Arc, epoch_start_configuration: Arc, - executed_in_epoch_table_enabled: once_cell::sync::OnceCell, - /// Execution state that has to restart at each epoch change execution_component: ExecutionComponents, @@ -481,10 +479,6 @@ pub struct AuthorityEpochTables { #[default_options_override_fn = "pending_consensus_transactions_table_default_config"] pending_consensus_transactions: DBMap, - /// this table is not used - #[allow(dead_code)] - consensus_message_order: DBMap, - /// The following table is used to store a single value (the corresponding /// key is a constant). The value represents the index of the latest /// consensus message this authority processed. This field is written by @@ -500,10 +494,6 @@ pub struct AuthorityEpochTables { /// This field is written by a single process (consensus handler). last_consensus_stats: DBMap, - /// this table is not used - #[allow(dead_code)] - checkpoint_boundary: DBMap, - /// This table contains current reconfiguration state for validator for /// current epoch reconfig_state: DBMap, @@ -511,10 +501,6 @@ pub struct AuthorityEpochTables { /// Validators that have sent EndOfPublish message in this epoch end_of_publish: DBMap, - // TODO: Unused. Remove when removal of DBMap tables is supported. - #[allow(dead_code)] - final_epoch_checkpoint: DBMap, - /// This table has information for the checkpoints for which we constructed /// all the data from consensus, but not yet constructed actual /// checkpoint. @@ -527,7 +513,7 @@ pub struct AuthorityEpochTables { /// with empty content(see CheckpointBuilder::write_checkpoint), /// the sequence number of checkpoint does not match height here. #[default_options_override_fn = "pending_checkpoints_table_default_config"] - pending_checkpoints: DBMap, + pending_checkpoints: DBMap, /// Checkpoint builder maintains internal list of transactions it included /// in checkpoints here @@ -548,12 +534,9 @@ pub struct AuthorityEpochTables { /// checkpoint later. user_signatures_for_checkpoints: DBMap>, - /// This table is not used - #[allow(dead_code)] - builder_checkpoint_summary: DBMap, /// Maps sequence number to checkpoint summary, used by CheckpointBuilder to /// build checkpoint within epoch - builder_checkpoint_summary_v2: DBMap, + builder_checkpoint_summary: DBMap, // Maps checkpoint sequence number to an accumulator with accumulated state // only for the checkpoint that the key references. Append-only, i.e., @@ -579,11 +562,6 @@ pub struct AuthorityEpochTables { pub(crate) executed_transactions_to_checkpoint: DBMap, - /// This table is no longer used (can be removed when DBMap supports - /// removing tables) - #[allow(dead_code)] - oauth_provider_jwk: DBMap, - /// JWKs that have been voted for by one or more authorities but are not yet /// active. pending_jwks: DBMap<(AuthorityName, JwkId, JWK), ()>, @@ -597,51 +575,31 @@ pub struct AuthorityEpochTables { /// Transactions that are being deferred until some future time deferred_transactions: DBMap>, - /// This table is no longer used (can be removed when DBMap supports - /// removing tables) - #[allow(dead_code)] - randomness_rounds_written: DBMap, - /// Tables for recording state for RandomnessManager. /// Records messages processed from other nodes. Updated when receiving a /// new dkg::Message via consensus. - pub(crate) dkg_processed_messages_v2: DBMap, - /// This table is no longer used (can be removed when DBMap supports - /// removing tables) - #[allow(dead_code)] - #[deprecated] - pub(crate) dkg_processed_messages: DBMap>, + pub(crate) dkg_processed_messages: DBMap, /// Records messages used to generate a DKG confirmation. Updated when /// enough DKG messages are received to progress to the next phase. - pub(crate) dkg_used_messages_v2: DBMap, - /// This table is no longer used (can be removed when DBMap supports - /// removing tables) - #[allow(dead_code)] - #[deprecated] - pub(crate) dkg_used_messages: DBMap>, + pub(crate) dkg_used_messages: DBMap, /// Records confirmations received from other nodes. Updated when receiving /// a new dkg::Confirmation via consensus. - pub(crate) dkg_confirmations_v2: DBMap, - /// This table is no longer used (can be removed when DBMap supports - /// removing tables) - #[allow(dead_code)] - #[deprecated] - pub(crate) dkg_confirmations: DBMap>, + pub(crate) dkg_confirmations: DBMap, + /// Records the final output of DKG after completion, including the public /// VSS key and any local private shares. pub(crate) dkg_output: DBMap>, - /// This table is no longer used (can be removed when DBMap supports - /// removing tables) - #[allow(dead_code)] - randomness_rounds_pending: DBMap, + /// Holds the value of the next RandomnessRound to be generated. pub(crate) randomness_next_round: DBMap, + /// Holds the value of the highest completed RandomnessRound (as reported to /// RandomnessReporter). pub(crate) randomness_highest_completed_round: DBMap, + /// Holds the timestamp of the most recently generated round of randomness. pub(crate) randomness_last_round_timestamp: DBMap, } @@ -923,13 +881,13 @@ impl AuthorityPerEpochStore { epoch_close_time: Default::default(), metrics, epoch_start_configuration, - executed_in_epoch_table_enabled: once_cell::sync::OnceCell::new(), execution_component, chain_identifier, jwk_aggregator, randomness_manager: OnceCell::new(), randomness_reporter: OnceCell::new(), }); + s.update_buffer_stake_metric(); s } @@ -1001,23 +959,6 @@ impl AuthorityPerEpochStore { self.parent_path.clone() } - pub fn state_accumulator_v2_enabled(&self) -> bool { - let flag = match self.get_chain_identifier().chain() { - Chain::Unknown | Chain::Testnet => EpochFlag::StateAccumulatorV2EnabledTestnet, - Chain::Mainnet => EpochFlag::StateAccumulatorV2EnabledMainnet, - }; - - self.epoch_start_configuration.flags().contains(&flag) - } - - pub fn executed_in_epoch_table_enabled(&self) -> bool { - *self.executed_in_epoch_table_enabled.get_or_init(|| { - self.epoch_start_configuration - .flags() - .contains(&EpochFlag::ExecutedInEpochTable) - }) - } - /// Returns `&Arc` /// User can treat this `Arc` as `&EpochStartConfiguration`, or clone the /// Arc to pass as owned object @@ -1233,28 +1174,15 @@ impl AuthorityPerEpochStore { } #[instrument(level = "trace", skip_all)] - pub fn insert_tx_key_and_effects_signature( + pub fn insert_tx_key_and_digest( &self, tx_key: &TransactionKey, tx_digest: &TransactionDigest, - effects_digest: &TransactionEffectsDigest, - effects_signature: Option<&AuthoritySignInfo>, ) -> IotaResult { let tables = self.tables()?; let mut batch = self.tables()?.effects_signatures.batch(); - if self.executed_in_epoch_table_enabled() { - batch.insert_batch(&tables.executed_in_epoch, [(tx_digest, ())])?; - } - - if let Some(effects_signature) = effects_signature { - batch.insert_batch(&tables.effects_signatures, [(tx_digest, effects_signature)])?; - - batch.insert_batch(&tables.signed_effects_digests, [( - tx_digest, - effects_digest, - )])?; - } + batch.insert_batch(&tables.executed_in_epoch, [(tx_digest, ())])?; if !matches!(tx_key, TransactionKey::Digest(_)) { batch.insert_batch(&tables.transaction_key_to_digest, [(tx_key, tx_digest)])?; @@ -1298,11 +1226,7 @@ impl AuthorityPerEpochStore { digests: impl IntoIterator, ) -> IotaResult> { let tables = self.tables()?; - if self.executed_in_epoch_table_enabled() { - Ok(tables.executed_in_epoch.multi_contains_keys(digests)?) - } else { - Ok(tables.effects_signatures.multi_contains_keys(digests)?) - } + Ok(tables.executed_in_epoch.multi_contains_keys(digests)?) } pub fn get_effects_signature( @@ -1414,23 +1338,6 @@ impl AuthorityPerEpochStore { .map_err(Into::into) } - /// Returns future containing the state digest for the given epoch - /// once available. - /// TODO: remove once StateAccumulatorV1 is removed - pub async fn notify_read_checkpoint_state_digests( - &self, - checkpoints: Vec, - ) -> IotaResult> { - self.checkpoint_state_notify_read - .read(&checkpoints, |checkpoints| -> IotaResult<_> { - Ok(self - .tables()? - .state_hash_by_checkpoint - .multi_get(checkpoints)?) - }) - .await - } - pub async fn notify_read_running_root( &self, checkpoint: CheckpointSequenceNumber, @@ -2798,7 +2705,7 @@ impl AuthorityPerEpochStore { checkpoint_roots.push(consensus_commit_prologue_root); } checkpoint_roots.extend(roots.into_iter()); - let pending_checkpoint = PendingCheckpointV2::V2(PendingCheckpointV2Contents { + let pending_checkpoint = PendingCheckpoint::V1(PendingCheckpointContentsV1 { roots: checkpoint_roots, details: PendingCheckpointInfo { timestamp_ms: consensus_commit_info.timestamp, @@ -2821,7 +2728,7 @@ impl AuthorityPerEpochStore { )); } if randomness_round.is_some() || (dkg_failed && !randomness_roots.is_empty()) { - let pending_checkpoint = PendingCheckpointV2::V2(PendingCheckpointV2Contents { + let pending_checkpoint = PendingCheckpoint::V1(PendingCheckpointContentsV1 { roots: randomness_roots.into_iter().collect(), details: PendingCheckpointInfo { timestamp_ms: consensus_commit_info.timestamp, @@ -3688,7 +3595,7 @@ impl AuthorityPerEpochStore { pub(crate) fn write_pending_checkpoint( &self, output: &mut ConsensusCommitOutput, - checkpoint: &PendingCheckpointV2, + checkpoint: &PendingCheckpoint, ) -> IotaResult { assert!( self.get_pending_checkpoint(&checkpoint.height())?.is_none(), @@ -3715,7 +3622,7 @@ impl AuthorityPerEpochStore { pub fn get_pending_checkpoints( &self, last: Option, - ) -> IotaResult> { + ) -> IotaResult> { let tables = self.tables()?; let mut iter = tables.pending_checkpoints.unbounded_iter(); if let Some(last_processed_height) = last { @@ -3727,7 +3634,7 @@ impl AuthorityPerEpochStore { pub fn get_pending_checkpoint( &self, index: &CheckpointHeight, - ) -> IotaResult> { + ) -> IotaResult> { Ok(self.tables()?.pending_checkpoints.get(index)?) } @@ -3748,7 +3655,7 @@ impl AuthorityPerEpochStore { checkpoint_height: Some(commit_height), position_in_commit, }; - batch.insert_batch(&self.tables()?.builder_checkpoint_summary_v2, [( + batch.insert_batch(&self.tables()?.builder_checkpoint_summary, [( &sequence_number, summary, )])?; @@ -3786,7 +3693,7 @@ impl AuthorityPerEpochStore { position_in_commit: 0, }; self.tables()? - .builder_checkpoint_summary_v2 + .builder_checkpoint_summary .insert(summary.sequence_number(), &builder_summary)?; Ok(()) } @@ -3796,7 +3703,7 @@ impl AuthorityPerEpochStore { ) -> IotaResult> { Ok(self .tables()? - .builder_checkpoint_summary_v2 + .builder_checkpoint_summary .unbounded_iter() .skip_to_last() .next() @@ -3808,7 +3715,7 @@ impl AuthorityPerEpochStore { ) -> IotaResult> { Ok(self .tables()? - .builder_checkpoint_summary_v2 + .builder_checkpoint_summary .unbounded_iter() .skip_to_last() .next() @@ -3821,7 +3728,7 @@ impl AuthorityPerEpochStore { ) -> IotaResult> { Ok(self .tables()? - .builder_checkpoint_summary_v2 + .builder_checkpoint_summary .get(&sequence)? .map(|s| s.summary)) } @@ -3936,7 +3843,7 @@ impl AuthorityPerEpochStore { .set(self.epoch_open_time.elapsed().as_millis() as i64); } - pub(crate) fn update_authenticator_state(&self, update: &AuthenticatorStateUpdate) { + pub(crate) fn update_authenticator_state(&self, update: &AuthenticatorStateUpdateV1) { info!("Updating authenticator state: {:?}", update); for active_jwk in &update.new_active_jwks { let ActiveJwk { jwk_id, jwk, .. } = active_jwk; @@ -3949,12 +3856,6 @@ impl AuthorityPerEpochStore { } pub(crate) fn check_all_executed_transactions_in_checkpoint(&self) { - if !self.executed_in_epoch_table_enabled() { - error!( - "Cannot check executed transactions in checkpoint because executed_in_epoch table is not enabled" - ); - return; - } let tables = self.tables().unwrap(); info!("Verifying that all executed transactions are in a checkpoint"); @@ -4003,7 +3904,7 @@ pub(crate) struct ConsensusCommitOutput { // checkpoint state user_signatures_for_checkpoints: Vec<(TransactionDigest, Vec)>, - pending_checkpoints: Vec, + pending_checkpoints: Vec, // random beacon state next_randomness_round: Option<(RandomnessRound, TimestampMs)>, @@ -4077,7 +3978,7 @@ impl ConsensusCommitOutput { .extend(deferral_keys.iter().cloned()); } - fn insert_pending_checkpoint(&mut self, checkpoint: PendingCheckpointV2) { + fn insert_pending_checkpoint(&mut self, checkpoint: PendingCheckpoint) { self.pending_checkpoints.push(checkpoint); } @@ -4190,13 +4091,10 @@ impl ConsensusCommitOutput { )])?; } - batch.insert_batch(&tables.dkg_confirmations_v2, self.dkg_confirmations)?; - batch.insert_batch( - &tables.dkg_processed_messages_v2, - self.dkg_processed_messages, - )?; + batch.insert_batch(&tables.dkg_confirmations, self.dkg_confirmations)?; + batch.insert_batch(&tables.dkg_processed_messages, self.dkg_processed_messages)?; batch.insert_batch( - &tables.dkg_used_messages_v2, + &tables.dkg_used_messages, // using Option as iter self.dkg_used_message .into_iter() diff --git a/crates/iota-core/src/authority/authority_test_utils.rs b/crates/iota-core/src/authority/authority_test_utils.rs index 79de7005656..dfcd8ffdd1b 100644 --- a/crates/iota-core/src/authority/authority_test_utils.rs +++ b/crates/iota-core/src/authority/authority_test_utils.rs @@ -87,13 +87,11 @@ pub async fn execute_certificate_with_execution_error( ), IotaError, > { - let epoch_store = authority.load_epoch_store_one_call_per_task(); // We also check the incremental effects of the transaction on the live object // set against StateAccumulator for testing and regression detection. // We must do this before sending to consensus, otherwise consensus may already // lead to transaction execution and state change. - let state_acc = - StateAccumulator::new_for_tests(authority.get_accumulator_store().clone(), &epoch_store); + let state_acc = StateAccumulator::new_for_tests(authority.get_accumulator_store().clone()); let mut state = state_acc.accumulate_cached_live_object_set_for_testing(); if with_shared { diff --git a/crates/iota-core/src/authority/epoch_start_configuration.rs b/crates/iota-core/src/authority/epoch_start_configuration.rs index 7fede708562..7ae6446577a 100644 --- a/crates/iota-core/src/authority/epoch_start_configuration.rs +++ b/crates/iota-core/src/authority/epoch_start_configuration.rs @@ -54,40 +54,22 @@ pub trait EpochStartConfigTrait { // inconsistent with the released branch, and must be fixed. #[derive(Clone, Debug, Serialize, Deserialize, Eq, PartialEq)] pub enum EpochFlag { - // The deprecated flags have all been in production for long enough that - // we can have deleted the old code paths they were guarding. - // We retain them here in order not to break deserialization. - _InMemoryCheckpointRootsDeprecated = 0, - _PerEpochFinalizedTransactionsDeprecated = 1, - _ObjectLockSplitTablesDeprecated = 2, - - WritebackCacheEnabled = 3, - - // This flag was "burned" because it was deployed with a broken version of the code. The - // new flags below are required to enable state accumulator v2 - _StateAccumulatorV2EnabledDeprecated = 4, - StateAccumulatorV2EnabledTestnet = 5, - StateAccumulatorV2EnabledMainnet = 6, - - ExecutedInEpochTable = 7, + WritebackCacheEnabled = 0, } impl EpochFlag { pub fn default_flags_for_new_epoch(config: &NodeConfig) -> Vec { - Self::default_flags_impl(&config.execution_cache, config.state_accumulator_v2) + Self::default_flags_impl(&config.execution_cache) } /// For situations in which there is no config available (e.g. setting up a /// downloaded snapshot). pub fn default_for_no_config() -> Vec { - Self::default_flags_impl(&Default::default(), true) + Self::default_flags_impl(&Default::default()) } - fn default_flags_impl( - cache_config: &ExecutionCacheConfig, - enable_state_accumulator_v2: bool, - ) -> Vec { - let mut new_flags = vec![EpochFlag::ExecutedInEpochTable]; + fn default_flags_impl(cache_config: &ExecutionCacheConfig) -> Vec { + let mut new_flags = vec![]; if matches!( choose_execution_cache(cache_config), @@ -96,11 +78,6 @@ impl EpochFlag { new_flags.push(EpochFlag::WritebackCacheEnabled); } - if enable_state_accumulator_v2 { - new_flags.push(EpochFlag::StateAccumulatorV2EnabledTestnet); - new_flags.push(EpochFlag::StateAccumulatorV2EnabledMainnet); - } - new_flags } } @@ -110,26 +87,7 @@ impl fmt::Display for EpochFlag { // Important - implementation should return low cardinality values because this // is used as metric key match self { - EpochFlag::_InMemoryCheckpointRootsDeprecated => { - write!(f, "InMemoryCheckpointRoots (DEPRECATED)") - } - EpochFlag::_PerEpochFinalizedTransactionsDeprecated => { - write!(f, "PerEpochFinalizedTransactions (DEPRECATED)") - } - EpochFlag::_ObjectLockSplitTablesDeprecated => { - write!(f, "ObjectLockSplitTables (DEPRECATED)") - } EpochFlag::WritebackCacheEnabled => write!(f, "WritebackCacheEnabled"), - EpochFlag::_StateAccumulatorV2EnabledDeprecated => { - write!(f, "StateAccumulatorV2EnabledDeprecated (DEPRECATED)") - } - EpochFlag::ExecutedInEpochTable => write!(f, "ExecutedInEpochTable"), - EpochFlag::StateAccumulatorV2EnabledTestnet => { - write!(f, "StateAccumulatorV2EnabledTestnet") - } - EpochFlag::StateAccumulatorV2EnabledMainnet => { - write!(f, "StateAccumulatorV2EnabledMainnet") - } } } } diff --git a/crates/iota-core/src/checkpoints/checkpoint_executor/tests.rs b/crates/iota-core/src/checkpoints/checkpoint_executor/tests.rs index c3ddaea1570..9dd7463d1a5 100644 --- a/crates/iota-core/src/checkpoints/checkpoint_executor/tests.rs +++ b/crates/iota-core/src/checkpoints/checkpoint_executor/tests.rs @@ -409,10 +409,8 @@ async fn init_executor_test( let (checkpoint_sender, _): (Sender, Receiver) = broadcast::channel(buffer_size); - let epoch_store = state.epoch_store_for_testing(); - let accumulator = - StateAccumulator::new_for_tests(state.get_accumulator_store().clone(), &epoch_store); + let accumulator = StateAccumulator::new_for_tests(state.get_accumulator_store().clone()); let accumulator = Arc::new(accumulator); let executor = CheckpointExecutor::new_for_tests( @@ -468,7 +466,7 @@ async fn sync_end_of_epoch_checkpoint( epoch_commitments: vec![ECMHLiveObjectSetDigest::default().into()], // Do not simulate supply changes in tests. // We would need to build this checkpoint after the below execution of advance_epoch to - // obtain this number from the SystemEpochInfoEvent. + // obtain this number from the SystemEpochInfoEventV1. epoch_supply_change: 0, }), ); diff --git a/crates/iota-core/src/checkpoints/mod.rs b/crates/iota-core/src/checkpoints/mod.rs index f1dc1e1a75d..c7b56a7cd34 100644 --- a/crates/iota-core/src/checkpoints/mod.rs +++ b/crates/iota-core/src/checkpoints/mod.rs @@ -33,7 +33,7 @@ use iota_types::{ digests::{CheckpointContentsDigest, CheckpointDigest}, effects::{TransactionEffects, TransactionEffectsAPI}, error::{IotaError, IotaResult}, - event::SystemEpochInfoEvent, + event::SystemEpochInfoEventV1, executable_transaction::VerifiedExecutableTransaction, gas::GasCostSummary, iota_system_state::{ @@ -102,54 +102,36 @@ pub struct PendingCheckpointInfo { } #[derive(Clone, Debug, Serialize, Deserialize)] -pub struct PendingCheckpoint { - pub roots: Vec, - pub details: PendingCheckpointInfo, -} - -#[derive(Clone, Debug, Serialize, Deserialize)] -pub enum PendingCheckpointV2 { +pub enum PendingCheckpoint { // This is an enum for future upgradability, though at the moment there is only one variant. - V2(PendingCheckpointV2Contents), + V1(PendingCheckpointContentsV1), } #[derive(Clone, Debug, Serialize, Deserialize)] -pub struct PendingCheckpointV2Contents { +pub struct PendingCheckpointContentsV1 { pub roots: Vec, pub details: PendingCheckpointInfo, } -impl PendingCheckpointV2 { - pub fn as_v2(&self) -> &PendingCheckpointV2Contents { +impl PendingCheckpoint { + pub fn as_v1(&self) -> &PendingCheckpointContentsV1 { match self { - PendingCheckpointV2::V2(contents) => contents, + PendingCheckpoint::V1(contents) => contents, } } - pub fn into_v2(self) -> PendingCheckpointV2Contents { + pub fn into_v1(self) -> PendingCheckpointContentsV1 { match self { - PendingCheckpointV2::V2(contents) => contents, - } - } - - pub fn expect_v1(self) -> PendingCheckpoint { - let v2 = self.into_v2(); - PendingCheckpoint { - roots: v2 - .roots - .into_iter() - .map(|root| *root.unwrap_digest()) - .collect(), - details: v2.details, + PendingCheckpoint::V1(contents) => contents, } } pub fn roots(&self) -> &Vec { - &self.as_v2().roots + &self.as_v1().roots } pub fn details(&self) -> &PendingCheckpointInfo { - &self.as_v2().details + &self.as_v1().details } pub fn height(&self) -> CheckpointHeight { @@ -1037,7 +1019,7 @@ impl CheckpointBuilder { } #[instrument(level = "debug", skip_all, fields(last_height = pendings.last().unwrap().details().checkpoint_height))] - async fn make_checkpoint(&self, pendings: Vec) -> anyhow::Result<()> { + async fn make_checkpoint(&self, pendings: Vec) -> anyhow::Result<()> { let last_details = pendings.last().unwrap().details().clone(); // Keeps track of the effects that are already included in the current @@ -1051,7 +1033,7 @@ impl CheckpointBuilder { // Transactions will be recorded in the checkpoint in this order. let mut sorted_tx_effects_included_in_checkpoint = Vec::new(); for pending_checkpoint in pendings.into_iter() { - let pending = pending_checkpoint.into_v2(); + let pending = pending_checkpoint.into_v1(); let txn_in_checkpoint = self .resolve_checkpoint_transactions(pending.roots, &mut effects_in_current_checkpoint) .await?; @@ -1376,8 +1358,9 @@ impl CheckpointBuilder { .unwrap_or_else(|| panic!("Could not find executed transaction {:?}", effects)); match transaction.inner().transaction_data().kind() { TransactionKind::ConsensusCommitPrologueV1(_) - | TransactionKind::AuthenticatorStateUpdate(_) => { - // ConsensusCommitPrologue and AuthenticatorStateUpdate + | TransactionKind::AuthenticatorStateUpdateV1(_) => { + // ConsensusCommitPrologue and + // AuthenticatorStateUpdateV1 // are guaranteed to be // processed before we reach here. } @@ -1591,7 +1574,7 @@ impl CheckpointBuilder { checkpoint_effects: &mut Vec, signatures: &mut Vec>, checkpoint: CheckpointSequenceNumber, - ) -> anyhow::Result<(IotaSystemState, SystemEpochInfoEvent)> { + ) -> anyhow::Result<(IotaSystemState, SystemEpochInfoEventV1)> { let (system_state, system_epoch_info_event, effects) = self .state .create_and_execute_advance_epoch_tx( @@ -2316,7 +2299,7 @@ impl CheckpointService { fn write_and_notify_checkpoint_for_testing( &self, epoch_store: &AuthorityPerEpochStore, - checkpoint: PendingCheckpointV2, + checkpoint: PendingCheckpoint, ) -> IotaResult { use crate::authority::authority_per_epoch_store::ConsensusCommitOutput; @@ -2397,27 +2380,6 @@ impl CheckpointServiceNotify for CheckpointServiceNoop { } } -impl PendingCheckpoint { - pub fn height(&self) -> CheckpointHeight { - self.details.checkpoint_height - } -} - -impl PendingCheckpointV2 {} - -impl From for PendingCheckpointV2 { - fn from(value: PendingCheckpoint) -> Self { - PendingCheckpointV2::V2(PendingCheckpointV2Contents { - roots: value - .roots - .into_iter() - .map(TransactionKey::Digest) - .collect(), - details: value.details, - }) - } -} - #[cfg(test)] mod tests { use std::{ @@ -2430,7 +2392,7 @@ mod tests { use iota_protocol_config::{Chain, ProtocolConfig}; use iota_types::{ base_types::{ObjectID, SequenceNumber, TransactionEffectsDigest}, - crypto::{AuthoritySignInfo, Signature}, + crypto::Signature, digests::TransactionEventsDigest, effects::{TransactionEffects, TransactionEvents}, messages_checkpoint::SignedCheckpointSummary, @@ -2438,7 +2400,6 @@ mod tests { object, transaction::{GenesisObject, VerifiedTransaction}, }; - use shared_crypto::intent::{Intent, IntentScope}; use tokio::sync::mpsc; use super::*; @@ -2561,7 +2522,6 @@ mod tests { let accumulator = Arc::new(StateAccumulator::new_for_tests( state.get_accumulator_store().clone(), - &epoch_store, )); let (checkpoint_service, _exit) = CheckpointService::spawn( @@ -2765,8 +2725,8 @@ mod tests { } } - fn p(i: u64, t: Vec, timestamp_ms: u64) -> PendingCheckpointV2 { - PendingCheckpointV2::V2(PendingCheckpointV2Contents { + fn p(i: u64, t: Vec, timestamp_ms: u64) -> PendingCheckpoint { + PendingCheckpoint::V1(PendingCheckpointContentsV1 { roots: t .into_iter() .map(|t| TransactionKey::Digest(d(t))) @@ -2808,18 +2768,7 @@ mod tests { let effects = e(digest, dependencies, gas_used); store.insert(digest, effects.clone()); epoch_store - .insert_tx_key_and_effects_signature( - &TransactionKey::Digest(digest), - &digest, - &effects.digest(), - Some(&AuthoritySignInfo::new( - epoch_store.epoch(), - &effects, - Intent::iota_app(IntentScope::TransactionEffects), - state.name, - &*state.secret, - )), - ) + .insert_tx_key_and_digest(&TransactionKey::Digest(digest), &digest) .expect("Inserting cert fx and sigs should not fail"); } } diff --git a/crates/iota-core/src/consensus_handler.rs b/crates/iota-core/src/consensus_handler.rs index 78b37ab4f86..de40d9523fa 100644 --- a/crates/iota-core/src/consensus_handler.rs +++ b/crates/iota-core/src/consensus_handler.rs @@ -260,7 +260,7 @@ impl ConsensusHandler { let authenticator_state_update_transaction = self.authenticator_state_update_transaction(round, new_jwks); debug!( - "adding AuthenticatorStateUpdate({:?}) tx: {:?}", + "adding AuthenticatorStateUpdateV1({:?}) tx: {:?}", authenticator_state_update_transaction.digest(), authenticator_state_update_transaction, ); diff --git a/crates/iota-core/src/epoch/randomness.rs b/crates/iota-core/src/epoch/randomness.rs index e94279ed176..677f6552e5a 100644 --- a/crates/iota-core/src/epoch/randomness.rs +++ b/crates/iota-core/src/epoch/randomness.rs @@ -352,12 +352,12 @@ impl RandomnessManager { ); rm.processed_messages.extend( tables - .dkg_processed_messages_v2 + .dkg_processed_messages .safe_iter() .map(|result| result.expect("typed_store should not fail")), ); if let Some(used_messages) = tables - .dkg_used_messages_v2 + .dkg_used_messages .get(&SINGLETON_KEY) .expect("typed_store should not fail") { @@ -367,7 +367,7 @@ impl RandomnessManager { } rm.confirmations.extend( tables - .dkg_confirmations_v2 + .dkg_confirmations .safe_iter() .map(|result| result.expect("typed_store should not fail")), ); diff --git a/crates/iota-core/src/quorum_driver/mod.rs b/crates/iota-core/src/quorum_driver/mod.rs index 896315208d7..80070a9e201 100644 --- a/crates/iota-core/src/quorum_driver/mod.rs +++ b/crates/iota-core/src/quorum_driver/mod.rs @@ -28,7 +28,7 @@ use iota_types::{ messages_grpc::HandleCertificateRequestV3, messages_safe_client::PlainTransactionInfoResponse, quorum_driver_types::{ - ExecuteTransactionRequestV3, QuorumDriverEffectsQueueResult, QuorumDriverError, + ExecuteTransactionRequestV1, QuorumDriverEffectsQueueResult, QuorumDriverError, QuorumDriverResponse, QuorumDriverResult, }, transaction::{CertifiedTransaction, Transaction}, @@ -62,7 +62,7 @@ const TX_MAX_RETRY_TIMES: u32 = 10; #[derive(Clone)] pub struct QuorumDriverTask { - pub request: ExecuteTransactionRequestV3, + pub request: ExecuteTransactionRequestV1, pub tx_cert: Option, pub retry_times: u32, pub next_retry_after: Instant, @@ -148,7 +148,7 @@ impl QuorumDriver { /// If it has, notify failure. async fn enqueue_again_maybe( &self, - request: ExecuteTransactionRequestV3, + request: ExecuteTransactionRequestV1, tx_cert: Option, old_retry_times: u32, client_addr: Option, @@ -176,7 +176,7 @@ impl QuorumDriver { /// backoff duration will be at least `min_backoff_duration`. async fn backoff_and_enqueue( &self, - request: ExecuteTransactionRequestV3, + request: ExecuteTransactionRequestV1, tx_cert: Option, old_retry_times: u32, client_addr: Option, @@ -252,7 +252,7 @@ where #[instrument(level = "trace", skip_all)] pub async fn submit_transaction( &self, - request: ExecuteTransactionRequestV3, + request: ExecuteTransactionRequestV1, ) -> IotaResult> { let tx_digest = request.transaction.digest(); debug!(?tx_digest, "Received transaction execution request."); @@ -277,7 +277,7 @@ where #[instrument(level = "trace", skip_all)] pub async fn submit_transaction_no_ticket( &self, - request: ExecuteTransactionRequestV3, + request: ExecuteTransactionRequestV1, client_addr: Option, ) -> IotaResult<()> { let tx_digest = request.transaction.digest(); @@ -691,7 +691,7 @@ where // TransactionOrchestrator pub async fn submit_transaction_no_ticket( &self, - request: ExecuteTransactionRequestV3, + request: ExecuteTransactionRequestV1, client_addr: Option, ) -> IotaResult<()> { self.quorum_driver @@ -701,7 +701,7 @@ where pub async fn submit_transaction( &self, - request: ExecuteTransactionRequestV3, + request: ExecuteTransactionRequestV1, ) -> IotaResult> { self.quorum_driver.submit_transaction(request).await } @@ -891,7 +891,7 @@ where fn handle_error( quorum_driver: Arc>, - request: ExecuteTransactionRequestV3, + request: ExecuteTransactionRequestV1, err: Option, tx_cert: Option, old_retry_times: u32, diff --git a/crates/iota-core/src/quorum_driver/tests.rs b/crates/iota-core/src/quorum_driver/tests.rs index f764526036c..7f3f94659c4 100644 --- a/crates/iota-core/src/quorum_driver/tests.rs +++ b/crates/iota-core/src/quorum_driver/tests.rs @@ -19,7 +19,7 @@ use iota_types::{ effects::TransactionEffectsAPI, object::{Object, generate_test_gas_objects}, quorum_driver_types::{ - ExecuteTransactionRequestV3, QuorumDriverError, QuorumDriverResponse, QuorumDriverResult, + ExecuteTransactionRequestV1, QuorumDriverError, QuorumDriverResponse, QuorumDriverResult, }, transaction::Transaction, }; @@ -96,7 +96,7 @@ async fn test_quorum_driver_submit_transaction() { assert_eq!(*effects_cert.data().transaction_digest(), digest); }); let ticket = quorum_driver_handler - .submit_transaction(ExecuteTransactionRequestV3::new_v2(tx)) + .submit_transaction(ExecuteTransactionRequestV1::new(tx)) .await .unwrap(); verify_ticket_response(ticket, &digest).await; @@ -130,7 +130,7 @@ async fn test_quorum_driver_submit_transaction_no_ticket() { }); quorum_driver_handler .submit_transaction_no_ticket( - ExecuteTransactionRequestV3::new_v2(tx), + ExecuteTransactionRequestV1::new(tx), Some(SocketAddr::new([127, 0, 0, 1].into(), 0)), ) .await @@ -175,7 +175,7 @@ async fn test_quorum_driver_with_given_notify_read() { }); let ticket1 = notifier.register_one(&digest); let ticket2 = quorum_driver_handler - .submit_transaction(ExecuteTransactionRequestV3::new_v2(tx)) + .submit_transaction(ExecuteTransactionRequestV1::new(tx)) .await .unwrap(); verify_ticket_response(ticket1, &digest).await; @@ -212,7 +212,7 @@ async fn test_quorum_driver_update_validators_and_max_retry_times() { // This error should not happen in practice for benign validators and a working // client let ticket = quorum_driver - .submit_transaction(ExecuteTransactionRequestV3::new_v2(tx)) + .submit_transaction(ExecuteTransactionRequestV1::new(tx)) .await .unwrap(); // We have a timeout here to make the test fail fast if fails @@ -305,7 +305,7 @@ async fn test_quorum_driver_object_locked() -> Result<(), anyhow::Error> { let tx2 = make_tx(&gas, sender, &keypair, rgp); let res = quorum_driver - .submit_transaction(ExecuteTransactionRequestV3::new_v2(tx2)) + .submit_transaction(ExecuteTransactionRequestV1::new(tx2)) .await .unwrap() .await; @@ -357,7 +357,7 @@ async fn test_quorum_driver_object_locked() -> Result<(), anyhow::Error> { let tx2 = make_tx(&gas, sender, &keypair, rgp); let res = quorum_driver - .submit_transaction(ExecuteTransactionRequestV3::new_v2(tx2)) + .submit_transaction(ExecuteTransactionRequestV1::new(tx2)) .await .unwrap() .await; @@ -393,7 +393,7 @@ async fn test_quorum_driver_object_locked() -> Result<(), anyhow::Error> { let tx2_digest = *tx2.digest(); let res = quorum_driver - .submit_transaction(ExecuteTransactionRequestV3::new_v2(tx2)) + .submit_transaction(ExecuteTransactionRequestV1::new(tx2)) .await .unwrap() .await @@ -432,7 +432,7 @@ async fn test_quorum_driver_object_locked() -> Result<(), anyhow::Error> { let tx3 = make_tx(&gas, sender, &keypair, rgp); let res = quorum_driver - .submit_transaction(ExecuteTransactionRequestV3::new_v2(tx3)) + .submit_transaction(ExecuteTransactionRequestV1::new(tx3)) .await .unwrap() .await; @@ -481,7 +481,7 @@ async fn test_quorum_driver_object_locked() -> Result<(), anyhow::Error> { .is_ok() ); let res = quorum_driver - .submit_transaction(ExecuteTransactionRequestV3::new_v2(tx2)) + .submit_transaction(ExecuteTransactionRequestV1::new(tx2)) .await .unwrap() .await; @@ -531,7 +531,7 @@ async fn test_quorum_driver_object_locked() -> Result<(), anyhow::Error> { ); let res = quorum_driver - .submit_transaction(ExecuteTransactionRequestV3::new_v2(tx)) + .submit_transaction(ExecuteTransactionRequestV1::new(tx)) .await .unwrap() .await @@ -566,7 +566,7 @@ async fn test_quorum_driver_object_locked() -> Result<(), anyhow::Error> { let tx4 = make_tx(&gas, sender, &keypair, rgp); let res = quorum_driver - .submit_transaction(ExecuteTransactionRequestV3::new_v2(tx4.clone())) + .submit_transaction(ExecuteTransactionRequestV1::new(tx4.clone())) .await .unwrap() .await; @@ -657,7 +657,7 @@ async fn test_quorum_driver_handling_overload_and_retry() { // Submit the transaction, and check that it shouldn't return, and the number of // retries is within 300s timeout / 30s retry after duration = 10 times. let ticket = quorum_driver_handler - .submit_transaction(ExecuteTransactionRequestV3::new_v2(tx)) + .submit_transaction(ExecuteTransactionRequestV1::new(tx)) .await .unwrap(); match timeout(Duration::from_secs(300), ticket).await { diff --git a/crates/iota-core/src/state_accumulator.rs b/crates/iota-core/src/state_accumulator.rs index 3f862291682..755f624274a 100644 --- a/crates/iota-core/src/state_accumulator.rs +++ b/crates/iota-core/src/state_accumulator.rs @@ -45,7 +45,6 @@ impl StateAccumulatorMetrics { pub enum StateAccumulator { V1(StateAccumulatorV1), - V2(StateAccumulatorV2), } pub struct StateAccumulatorV1 { @@ -53,11 +52,6 @@ pub struct StateAccumulatorV1 { metrics: Arc, } -pub struct StateAccumulatorV2 { - store: Arc, - metrics: Arc, -} - pub trait AccumulatorStore: ObjectStore + Send + Sync { fn get_root_state_accumulator_for_epoch( &self, @@ -161,40 +155,23 @@ fn accumulate_effects(effects: Vec) -> Accumulator { } impl StateAccumulator { - pub fn new( - store: Arc, - epoch_store: &Arc, - metrics: Arc, - ) -> Self { - if epoch_store.state_accumulator_v2_enabled() { - StateAccumulator::V2(StateAccumulatorV2::new(store, metrics)) - } else { - StateAccumulator::V1(StateAccumulatorV1::new(store, metrics)) - } + pub fn new(store: Arc, metrics: Arc) -> Self { + StateAccumulator::V1(StateAccumulatorV1::new(store, metrics)) } - pub fn new_for_tests( - store: Arc, - epoch_store: &Arc, - ) -> Self { - Self::new( - store, - epoch_store, - StateAccumulatorMetrics::new(&Registry::new()), - ) + pub fn new_for_tests(store: Arc) -> Self { + Self::new(store, StateAccumulatorMetrics::new(&Registry::new())) } pub fn metrics(&self) -> Arc { match self { StateAccumulator::V1(impl_v1) => impl_v1.metrics.clone(), - StateAccumulator::V2(impl_v2) => impl_v2.metrics.clone(), } } pub fn set_inconsistent_state(&self, is_inconsistent_state: bool) { match self { StateAccumulator::V1(impl_v1) => &impl_v1.metrics, - StateAccumulator::V2(impl_v2) => &impl_v2.metrics, } .inconsistent_state .set(is_inconsistent_state as i64); @@ -232,12 +209,8 @@ impl StateAccumulator { checkpoint_acc: Option, ) -> IotaResult { match self { - StateAccumulator::V1(_) => { - // V1 does not have a running root accumulator - Ok(()) - } - StateAccumulator::V2(impl_v2) => { - impl_v2 + StateAccumulator::V1(impl_v1) => { + impl_v1 .accumulate_running_root(epoch_store, checkpoint_seq_num, checkpoint_acc) .await } @@ -251,12 +224,7 @@ impl StateAccumulator { ) -> IotaResult { match self { StateAccumulator::V1(impl_v1) => { - impl_v1 - .accumulate_epoch(epoch_store, last_checkpoint_of_epoch) - .await - } - StateAccumulator::V2(impl_v2) => { - impl_v2.accumulate_epoch(epoch_store, last_checkpoint_of_epoch) + impl_v1.accumulate_epoch(epoch_store, last_checkpoint_of_epoch) } } } @@ -266,9 +234,6 @@ impl StateAccumulator { StateAccumulator::V1(impl_v1) => Self::accumulate_live_object_set_impl( impl_v1.store.iter_cached_live_object_set_for_testing(), ), - StateAccumulator::V2(impl_v2) => Self::accumulate_live_object_set_impl( - impl_v2.store.iter_cached_live_object_set_for_testing(), - ), } } @@ -279,9 +244,6 @@ impl StateAccumulator { StateAccumulator::V1(impl_v1) => { Self::accumulate_live_object_set_impl(impl_v1.store.iter_live_object_set()) } - StateAccumulator::V2(impl_v2) => { - Self::accumulate_live_object_set_impl(impl_v2.store.iter_live_object_set()) - } } } @@ -290,7 +252,6 @@ impl StateAccumulator { pub fn accumulate_effects(&self, effects: Vec) -> Accumulator { match self { StateAccumulator::V1(impl_v1) => impl_v1.accumulate_effects(effects), - StateAccumulator::V2(impl_v2) => impl_v2.accumulate_effects(effects), } } @@ -339,92 +300,6 @@ impl StateAccumulatorV1 { Self { store, metrics } } - /// Unions all checkpoint accumulators at the end of the epoch to generate - /// the root state hash and persists it to db. This function is - /// idempotent. Can be called on non-consecutive epochs, e.g. to - /// accumulate epoch 3 after having last accumulated epoch 1. - pub async fn accumulate_epoch( - &self, - epoch_store: Arc, - last_checkpoint_of_epoch: CheckpointSequenceNumber, - ) -> IotaResult { - let _scope = monitored_scope("AccumulateEpochV1"); - let epoch = epoch_store.epoch(); - if let Some((_checkpoint, acc)) = self.store.get_root_state_accumulator_for_epoch(epoch)? { - return Ok(acc); - } - - // Get the next checkpoint to accumulate (first checkpoint of the epoch) - // by adding 1 to the highest checkpoint of the previous epoch - let (_highest_epoch, (next_to_accumulate, mut root_state_accumulator)) = self - .store - .get_root_state_accumulator_for_highest_epoch()? - .map(|(epoch, (checkpoint, acc))| { - ( - epoch, - ( - checkpoint - .checked_add(1) - .expect("Overflowed u64 for epoch ID"), - acc, - ), - ) - }) - .unwrap_or((0, (0, Accumulator::default()))); - - debug!( - "Accumulating epoch {} from checkpoint {} to checkpoint {} (inclusive)", - epoch, next_to_accumulate, last_checkpoint_of_epoch - ); - - let (checkpoints, mut accumulators) = epoch_store - .get_accumulators_in_checkpoint_range(next_to_accumulate, last_checkpoint_of_epoch)? - .into_iter() - .unzip::<_, _, Vec<_>, Vec<_>>(); - - let remaining_checkpoints: Vec<_> = (next_to_accumulate..=last_checkpoint_of_epoch) - .filter(|seq_num| !checkpoints.contains(seq_num)) - .collect(); - - if !remaining_checkpoints.is_empty() { - debug!( - "Awaiting accumulation of checkpoints {:?} for epoch {} accumulation", - remaining_checkpoints, epoch - ); - } - - let mut remaining_accumulators = epoch_store - .notify_read_checkpoint_state_digests(remaining_checkpoints) - .await - .expect("Failed to notify read checkpoint state digests"); - - accumulators.append(&mut remaining_accumulators); - - assert!(accumulators.len() == (last_checkpoint_of_epoch - next_to_accumulate + 1) as usize); - - for acc in accumulators { - root_state_accumulator.union(&acc); - } - - self.store.insert_state_accumulator_for_epoch( - epoch, - &last_checkpoint_of_epoch, - &root_state_accumulator, - )?; - - Ok(root_state_accumulator) - } - - pub fn accumulate_effects(&self, effects: Vec) -> Accumulator { - accumulate_effects(effects) - } -} - -impl StateAccumulatorV2 { - pub fn new(store: Arc, metrics: Arc) -> Self { - Self { store, metrics } - } - pub async fn accumulate_running_root( &self, epoch_store: &AuthorityPerEpochStore, diff --git a/crates/iota-core/src/test_utils.rs b/crates/iota-core/src/test_utils.rs index 4c62a7ab1d7..809ca04d8c5 100644 --- a/crates/iota-core/src/test_utils.rs +++ b/crates/iota-core/src/test_utils.rs @@ -79,8 +79,7 @@ pub async fn send_and_confirm_transaction( // // We also check the incremental effects of the transaction on the live object // set against StateAccumulator for testing and regression detection - let state_acc = - StateAccumulator::new_for_tests(authority.get_accumulator_store().clone(), &epoch_store); + let state_acc = StateAccumulator::new_for_tests(authority.get_accumulator_store().clone()); let mut state = state_acc.accumulate_live_object_set(); let (result, _execution_error_opt) = authority.try_execute_for_test(&certificate).await?; let state_after = state_acc.accumulate_live_object_set(); diff --git a/crates/iota-core/src/transaction_orchestrator.rs b/crates/iota-core/src/transaction_orchestrator.rs index 15e780e0f5c..c944bc6bb65 100644 --- a/crates/iota-core/src/transaction_orchestrator.rs +++ b/crates/iota-core/src/transaction_orchestrator.rs @@ -26,7 +26,7 @@ use iota_types::{ executable_transaction::VerifiedExecutableTransaction, iota_system_state::IotaSystemState, quorum_driver_types::{ - ExecuteTransactionRequestType, ExecuteTransactionRequestV3, ExecuteTransactionResponseV3, + ExecuteTransactionRequestType, ExecuteTransactionRequestV1, ExecuteTransactionResponseV1, FinalizedEffects, IsTransactionExecutedLocally, QuorumDriverEffectsQueueResult, QuorumDriverError, QuorumDriverResponse, QuorumDriverResult, }, @@ -158,10 +158,10 @@ where err)] pub async fn execute_transaction_block( &self, - request: ExecuteTransactionRequestV3, + request: ExecuteTransactionRequestV1, request_type: ExecuteTransactionRequestType, client_addr: Option, - ) -> Result<(ExecuteTransactionResponseV3, IsTransactionExecutedLocally), QuorumDriverError> + ) -> Result<(ExecuteTransactionResponseV1, IsTransactionExecutedLocally), QuorumDriverError> { let epoch_store = self.validator_state.load_epoch_store_one_call_per_task(); @@ -200,7 +200,7 @@ where auxiliary_data, } = response; - let response = ExecuteTransactionResponseV3 { + let response = ExecuteTransactionResponseV1 { effects: FinalizedEffects::new_from_effects_cert(effects_cert.into()), events, input_objects, @@ -213,13 +213,13 @@ where // Utilize the handle_certificate_v3 validator api to request input/output // objects - #[instrument(name = "tx_orchestrator_execute_transaction_v3", level = "trace", skip_all, + #[instrument(name = "tx_orchestrator_execute_transaction_v1", level = "trace", skip_all, fields(tx_digest = ?request.transaction.digest()))] - pub async fn execute_transaction_v3( + pub async fn execute_transaction_v1( &self, - request: ExecuteTransactionRequestV3, + request: ExecuteTransactionRequestV1, client_addr: Option, - ) -> Result { + ) -> Result { let epoch_store = self.validator_state.load_epoch_store_one_call_per_task(); let QuorumDriverResponse { @@ -233,7 +233,7 @@ where .await .map(|(_, r)| r)?; - Ok(ExecuteTransactionResponseV3 { + Ok(ExecuteTransactionResponseV1 { effects: FinalizedEffects::new_from_effects_cert(effects_cert.into()), events, input_objects, @@ -248,7 +248,7 @@ where pub async fn execute_transaction_impl( &self, epoch_store: &AuthorityPerEpochStore, - request: ExecuteTransactionRequestV3, + request: ExecuteTransactionRequestV1, client_addr: Option, ) -> Result<(VerifiedTransaction, QuorumDriverResponse), QuorumDriverError> { let transaction = epoch_store @@ -319,7 +319,7 @@ where async fn submit( &self, transaction: VerifiedTransaction, - request: ExecuteTransactionRequestV3, + request: ExecuteTransactionRequestV1, client_addr: Option, ) -> IotaResult> + '_> { let tx_digest = *transaction.digest(); @@ -536,7 +536,7 @@ where // world. TODO(william) correctly extract client_addr from logs if let Err(err) = quorum_driver .submit_transaction_no_ticket( - ExecuteTransactionRequestV3 { + ExecuteTransactionRequestV1 { transaction: tx, include_events: true, include_input_objects: false, @@ -735,9 +735,9 @@ where { async fn execute_transaction( &self, - request: ExecuteTransactionRequestV3, + request: ExecuteTransactionRequestV1, client_addr: Option, - ) -> Result { - self.execute_transaction_v3(request, client_addr).await + ) -> Result { + self.execute_transaction_v1(request, client_addr).await } } diff --git a/crates/iota-core/src/unit_tests/mysticeti_manager_tests.rs b/crates/iota-core/src/unit_tests/mysticeti_manager_tests.rs index 42f3f7d17ae..63b9d5fa6db 100644 --- a/crates/iota-core/src/unit_tests/mysticeti_manager_tests.rs +++ b/crates/iota-core/src/unit_tests/mysticeti_manager_tests.rs @@ -30,7 +30,6 @@ pub fn checkpoint_service_for_testing(state: Arc) -> Arc(10); diff --git a/crates/iota-core/src/unit_tests/transaction_tests.rs b/crates/iota-core/src/unit_tests/transaction_tests.rs index b054488bb08..34804bc4210 100644 --- a/crates/iota-core/src/unit_tests/transaction_tests.rs +++ b/crates/iota-core/src/unit_tests/transaction_tests.rs @@ -26,7 +26,7 @@ use iota_types::{ multisig::{MultiSig, MultiSigPublicKey}, signature::GenericSignature, transaction::{ - AuthenticatorStateUpdate, GenesisTransaction, TransactionDataAPI, TransactionKind, + AuthenticatorStateUpdateV1, GenesisTransaction, TransactionDataAPI, TransactionKind, }, utils::{get_one_zklogin_inputs, load_test_vectors, to_sender_signed_transaction}, zk_login_authenticator::ZkLoginAuthenticator, @@ -976,7 +976,7 @@ async fn setup_zklogin_network( let gas_object_id = gas_object_ids[0]; let jwks = parse_jwks(DEFAULT_JWK_BYTES, &OIDCProvider::Twitch)?; let epoch_store = authority_state.epoch_store_for_testing(); - epoch_store.update_authenticator_state(&AuthenticatorStateUpdate { + epoch_store.update_authenticator_state(&AuthenticatorStateUpdateV1 { epoch: 0, round: 0, new_active_jwks: jwks @@ -1153,7 +1153,7 @@ async fn test_zklogin_txn_fail_if_missing_jwk() { // Initialize an authenticator state with a Google JWK. let jwks = parse_jwks(DEFAULT_JWK_BYTES, &OIDCProvider::Google).unwrap(); let epoch_store = authority_state.epoch_store_for_testing(); - epoch_store.update_authenticator_state(&AuthenticatorStateUpdate { + epoch_store.update_authenticator_state(&AuthenticatorStateUpdateV1 { epoch: 0, round: 0, new_active_jwks: jwks @@ -1185,7 +1185,7 @@ async fn test_zklogin_txn_fail_if_missing_jwk() { // Initialize an authenticator state with Twitch's kid as "nosuckkey". pub const BAD_JWK_BYTES: &[u8] = r#"{"keys":[{"alg":"RS256","e":"AQAB","kid":"nosuchkey","kty":"RSA","n":"6lq9MQ-q6hcxr7kOUp-tHlHtdcDsVLwVIw13iXUCvuDOeCi0VSuxCCUY6UmMjy53dX00ih2E4Y4UvlrmmurK0eG26b-HMNNAvCGsVXHU3RcRhVoHDaOwHwU72j7bpHn9XbP3Q3jebX6KIfNbei2MiR0Wyb8RZHE-aZhRYO8_-k9G2GycTpvc-2GBsP8VHLUKKfAs2B6sW3q3ymU6M0L-cFXkZ9fHkn9ejs-sqZPhMJxtBPBxoUIUQFTgv4VXTSv914f_YkNw-EjuwbgwXMvpyr06EyfImxHoxsZkFYB-qBYHtaMxTnFsZBr6fn8Ha2JqT1hoP7Z5r5wxDu3GQhKkHw","use":"sig"}]}"#.as_bytes(); let jwks = parse_jwks(BAD_JWK_BYTES, &OIDCProvider::Twitch).unwrap(); - epoch_store.update_authenticator_state(&AuthenticatorStateUpdate { + epoch_store.update_authenticator_state(&AuthenticatorStateUpdateV1 { epoch: 0, round: 0, new_active_jwks: jwks @@ -1230,7 +1230,7 @@ async fn test_zklogin_multisig() { let jwks = parse_jwks(DEFAULT_JWK_BYTES, &OIDCProvider::Twitch).unwrap(); let epoch_store = authority_state.epoch_store_for_testing(); - epoch_store.update_authenticator_state(&AuthenticatorStateUpdate { + epoch_store.update_authenticator_state(&AuthenticatorStateUpdateV1 { epoch: 0, round: 0, new_active_jwks: jwks diff --git a/crates/iota-core/tests/staged/iota.yaml b/crates/iota-core/tests/staged/iota.yaml index 97847f906cd..93612022d94 100644 --- a/crates/iota-core/tests/staged/iota.yaml +++ b/crates/iota-core/tests/staged/iota.yaml @@ -31,7 +31,7 @@ AuthenticatorStateExpire: - min_epoch: U64 - authenticator_obj_initial_shared_version: TYPENAME: SequenceNumber -AuthenticatorStateUpdate: +AuthenticatorStateUpdateV1: STRUCT: - epoch: U64 - round: U64 @@ -1007,9 +1007,9 @@ TransactionKind: NEWTYPE: TYPENAME: ConsensusCommitPrologueV1 3: - AuthenticatorStateUpdate: + AuthenticatorStateUpdateV1: NEWTYPE: - TYPENAME: AuthenticatorStateUpdate + TYPENAME: AuthenticatorStateUpdateV1 4: EndOfEpochTransaction: NEWTYPE: diff --git a/crates/iota-e2e-tests/tests/full_node_tests.rs b/crates/iota-e2e-tests/tests/full_node_tests.rs index 27d81a766b6..899f314b5ad 100644 --- a/crates/iota-e2e-tests/tests/full_node_tests.rs +++ b/crates/iota-e2e-tests/tests/full_node_tests.rs @@ -33,7 +33,7 @@ use iota_types::{ object::{Object, ObjectRead, Owner, PastObjectRead}, programmable_transaction_builder::ProgrammableTransactionBuilder, quorum_driver_types::{ - ExecuteTransactionRequestType, ExecuteTransactionRequestV3, QuorumDriverResponse, + ExecuteTransactionRequestType, ExecuteTransactionRequestV1, QuorumDriverResponse, }, storage::ObjectStore, transaction::{ @@ -749,7 +749,7 @@ async fn test_full_node_transaction_orchestrator_basic() -> Result<(), anyhow::E let digest = *txn.digest(); let res = transaction_orchestrator .execute_transaction_block( - ExecuteTransactionRequestV3::new_v2(txn), + ExecuteTransactionRequestV1::new(txn), ExecuteTransactionRequestType::WaitForLocalExecution, None, ) @@ -784,7 +784,7 @@ async fn test_full_node_transaction_orchestrator_basic() -> Result<(), anyhow::E let digest = *txn.digest(); let res = transaction_orchestrator .execute_transaction_block( - ExecuteTransactionRequestV3::new_v2(txn), + ExecuteTransactionRequestV1::new(txn), ExecuteTransactionRequestType::WaitForEffectsCert, None, ) @@ -1194,7 +1194,7 @@ async fn test_pass_back_no_object() -> Result<(), anyhow::Error> { let digest = *tx.digest(); let _res = transaction_orchestrator .execute_transaction_block( - ExecuteTransactionRequestV3::new_v2(tx), + ExecuteTransactionRequestV1::new(tx), ExecuteTransactionRequestType::WaitForLocalExecution, None, ) diff --git a/crates/iota-e2e-tests/tests/protocol_version_tests.rs b/crates/iota-e2e-tests/tests/protocol_version_tests.rs index ba45057eb57..2deda364079 100644 --- a/crates/iota-e2e-tests/tests/protocol_version_tests.rs +++ b/crates/iota-e2e-tests/tests/protocol_version_tests.rs @@ -74,7 +74,7 @@ mod sim_only_tests { effects::{TransactionEffects, TransactionEffectsAPI}, id::ID, iota_system_state::{ - IOTA_SYSTEM_STATE_SIM_TEST_DEEP_V2, IOTA_SYSTEM_STATE_SIM_TEST_SHALLOW_V2, + IOTA_SYSTEM_STATE_SIM_TEST_DEEP_V1, IOTA_SYSTEM_STATE_SIM_TEST_SHALLOW_V1, IOTA_SYSTEM_STATE_SIM_TEST_V1, IotaSystemState, IotaSystemStateTrait, epoch_start_iota_system_state::EpochStartSystemStateTrait, get_validator_from_table, }, @@ -893,7 +893,7 @@ mod sim_only_tests { let system_state = test_cluster.wait_for_epoch(Some(2)).await; assert_eq!( system_state.system_state_version(), - IOTA_SYSTEM_STATE_SIM_TEST_SHALLOW_V2 + IOTA_SYSTEM_STATE_SIM_TEST_SHALLOW_V1 ); assert!(matches!(system_state, IotaSystemState::SimTestShallowV2(_))); } @@ -946,7 +946,7 @@ mod sim_only_tests { let system_state = test_cluster.wait_for_epoch(Some(2)).await; assert_eq!( system_state.system_state_version(), - IOTA_SYSTEM_STATE_SIM_TEST_DEEP_V2 + IOTA_SYSTEM_STATE_SIM_TEST_DEEP_V1 ); if let IotaSystemState::SimTestDeepV2(inner) = system_state { // Make sure we have 1 inactive validator for latter testing. @@ -991,7 +991,7 @@ mod sim_only_tests { // The system state object will be upgraded next time we execute advance_epoch // transaction at epoch boundary. let system_state = test_cluster.wait_for_epoch(Some(2)).await; - if let IotaSystemState::V2(inner) = system_state { + if let IotaSystemState::V1(inner) = system_state { assert_eq!(inner.parameters.min_validator_count, 4); } else { unreachable!("Unexpected iota system state version"); diff --git a/crates/iota-e2e-tests/tests/transaction_orchestrator_tests.rs b/crates/iota-e2e-tests/tests/transaction_orchestrator_tests.rs index 22ceee394c4..5248c92e6da 100644 --- a/crates/iota-e2e-tests/tests/transaction_orchestrator_tests.rs +++ b/crates/iota-e2e-tests/tests/transaction_orchestrator_tests.rs @@ -17,7 +17,7 @@ use iota_test_transaction_builder::{ use iota_types::{ effects::TransactionEffectsAPI, quorum_driver_types::{ - ExecuteTransactionRequestType, ExecuteTransactionRequestV3, ExecuteTransactionResponseV3, + ExecuteTransactionRequestType, ExecuteTransactionRequestV1, ExecuteTransactionResponseV1, FinalizedEffects, IsTransactionExecutedLocally, QuorumDriverError, }, transaction::Transaction, @@ -51,7 +51,7 @@ async fn test_blocking_execution() -> Result<(), anyhow::Error> { orchestrator .quorum_driver() .submit_transaction_no_ticket( - ExecuteTransactionRequestV3::new_v2(txn), + ExecuteTransactionRequestV1::new(txn), Some(make_socket_addr()), ) .await?; @@ -256,7 +256,7 @@ async fn test_tx_across_epoch_boundaries() { tokio::task::spawn(async move { match to .execute_transaction_block( - ExecuteTransactionRequestV3::new_v2(tx.clone()), + ExecuteTransactionRequestV1::new(tx.clone()), ExecuteTransactionRequestType::WaitForEffectsCert, None, ) @@ -297,14 +297,14 @@ async fn execute_with_orchestrator( orchestrator: &TransactionOrchestrator, txn: Transaction, request_type: ExecuteTransactionRequestType, -) -> Result<(ExecuteTransactionResponseV3, IsTransactionExecutedLocally), QuorumDriverError> { +) -> Result<(ExecuteTransactionResponseV1, IsTransactionExecutedLocally), QuorumDriverError> { orchestrator - .execute_transaction_block(ExecuteTransactionRequestV3::new_v2(txn), request_type, None) + .execute_transaction_block(ExecuteTransactionRequestV1::new(txn), request_type, None) .await } #[sim_test] -async fn execute_transaction_v3() -> Result<(), anyhow::Error> { +async fn execute_transaction_v1() -> Result<(), anyhow::Error> { let mut test_cluster = TestClusterBuilder::new().build().await; let context = &mut test_cluster.wallet; let handle = &test_cluster.fullnode_handle.iota_node; @@ -321,14 +321,14 @@ async fn execute_transaction_v3() -> Result<(), anyhow::Error> { // Quorum driver does not execute txn locally let txn = txns.swap_remove(0); - let request = ExecuteTransactionRequestV3 { + let request = ExecuteTransactionRequestV1 { transaction: txn, include_events: true, include_input_objects: true, include_output_objects: true, include_auxiliary_data: false, }; - let response = orchestrator.execute_transaction_v3(request, None).await?; + let response = orchestrator.execute_transaction_v1(request, None).await?; let fx = &response.effects.effects; let mut expected_input_objects = fx.modified_at_versions(); @@ -362,7 +362,7 @@ async fn execute_transaction_v3() -> Result<(), anyhow::Error> { } #[sim_test] -async fn execute_transaction_v3_staking_transaction() -> Result<(), anyhow::Error> { +async fn execute_transaction_v1_staking_transaction() -> Result<(), anyhow::Error> { let mut test_cluster = TestClusterBuilder::new().build().await; let context = &mut test_cluster.wallet; let handle = &test_cluster.fullnode_handle.iota_node; @@ -380,14 +380,14 @@ async fn execute_transaction_v3_staking_transaction() -> Result<(), anyhow::Erro .iota_address; let transaction = make_staking_transaction(context, validator_address).await; - let request = ExecuteTransactionRequestV3 { + let request = ExecuteTransactionRequestV1 { transaction, include_events: true, include_input_objects: true, include_output_objects: true, include_auxiliary_data: false, }; - let response = orchestrator.execute_transaction_v3(request, None).await?; + let response = orchestrator.execute_transaction_v1(request, None).await?; let fx = &response.effects.effects; let mut expected_input_objects = fx.modified_at_versions(); diff --git a/crates/iota-e2e-tests/tests/zklogin_tests.rs b/crates/iota-e2e-tests/tests/zklogin_tests.rs index 80b6e64be60..cc01a08dd03 100644 --- a/crates/iota-e2e-tests/tests/zklogin_tests.rs +++ b/crates/iota-e2e-tests/tests/zklogin_tests.rs @@ -199,8 +199,8 @@ async fn test_zklogin_auth_state_creation() { // Wait until we are in an epoch that has zklogin enabled, but the auth state // object is not created yet. test_cluster.wait_for_protocol_version(24.into()).await; - // Now wait until the auth state object is created, ie. AuthenticatorStateUpdate - // transaction happened. + // Now wait until the auth state object is created, ie. + // AuthenticatorStateUpdateV1 transaction happened. test_cluster.wait_for_authenticator_state_update().await; } @@ -289,7 +289,7 @@ async fn test_zklogin_conflicting_jwks() { .unwrap(); match &tx.data().intent_message().value.kind() { TransactionKind::EndOfEpochTransaction(_) => (), - TransactionKind::AuthenticatorStateUpdate(update) => { + TransactionKind::AuthenticatorStateUpdateV1(update) => { let jwks = &mut *jwks_clone.lock().unwrap(); for jwk in &update.new_active_jwks { jwks.push(jwk.clone()); diff --git a/crates/iota-framework-snapshot/bytecode_snapshot/1/0x0000000000000000000000000000000000000000000000000000000000000003 b/crates/iota-framework-snapshot/bytecode_snapshot/1/0x0000000000000000000000000000000000000000000000000000000000000003 index ce3112b38cb..c1a2b18de42 100644 Binary files a/crates/iota-framework-snapshot/bytecode_snapshot/1/0x0000000000000000000000000000000000000000000000000000000000000003 and b/crates/iota-framework-snapshot/bytecode_snapshot/1/0x0000000000000000000000000000000000000000000000000000000000000003 differ diff --git a/crates/iota-framework-snapshot/manifest.json b/crates/iota-framework-snapshot/manifest.json index 6273bb2a3c6..5fc48001399 100644 --- a/crates/iota-framework-snapshot/manifest.json +++ b/crates/iota-framework-snapshot/manifest.json @@ -1,6 +1,6 @@ { "1": { - "git_revision": "679ea04679f2", + "git_revision": "79d2e3399d20", "package_ids": [ "0x0000000000000000000000000000000000000000000000000000000000000001", "0x0000000000000000000000000000000000000000000000000000000000000002", diff --git a/crates/iota-framework/packages/iota-system/sources/genesis.move b/crates/iota-framework/packages/iota-system/sources/genesis.move index e5cc30a9acf..804298911cb 100644 --- a/crates/iota-framework/packages/iota-system/sources/genesis.move +++ b/crates/iota-framework/packages/iota-system/sources/genesis.move @@ -10,7 +10,7 @@ module iota_system::genesis { use iota::iota::{Self, IotaTreasuryCap}; use iota::timelock::SystemTimelockCap; use iota_system::iota_system; - use iota_system::validator::{Self, Validator}; + use iota_system::validator::{Self, ValidatorV1}; use iota_system::validator_set; use iota_system::iota_system_state_inner; use iota_system::timelocked_staking; @@ -42,7 +42,7 @@ module iota_system::genesis { chain_start_timestamp_ms: u64, epoch_duration_ms: u64, - // Validator committee parameters + // ValidatorV1 committee parameters max_validator_count: u64, min_validator_joining_stake: u64, validator_low_stake_threshold: u64, @@ -100,7 +100,7 @@ module iota_system::genesis { let storage_fund = balance::zero(); - // Create all the `Validator` structs + // Create all the `ValidatorV1` structs let mut validators = vector[]; let count = genesis_validators.length(); let mut i = 0; @@ -166,7 +166,7 @@ module iota_system::genesis { let system_parameters = iota_system_state_inner::create_system_parameters( genesis_chain_parameters.epoch_duration_ms, - // Validator committee parameters + // ValidatorV1 committee parameters genesis_chain_parameters.max_validator_count, genesis_chain_parameters.min_validator_joining_stake, genesis_chain_parameters.validator_low_stake_threshold, @@ -192,7 +192,7 @@ module iota_system::genesis { fun allocate_tokens( iota_treasury_cap: &mut IotaTreasuryCap, mut allocations: vector, - validators: &mut vector, + validators: &mut vector, timelock_genesis_label: Option, ctx: &mut TxContext, ) { @@ -239,7 +239,7 @@ module iota_system::genesis { allocations.destroy_empty(); } - fun activate_validators(validators: &mut vector) { + fun activate_validators(validators: &mut vector) { // Activate all genesis validators let count = validators.length(); let mut i = 0; diff --git a/crates/iota-framework/packages/iota-system/sources/iota_system.move b/crates/iota-framework/packages/iota-system/sources/iota_system.move index 53765bdecfd..09da71387a4 100644 --- a/crates/iota-framework/packages/iota-system/sources/iota_system.move +++ b/crates/iota-framework/packages/iota-system/sources/iota_system.move @@ -3,24 +3,24 @@ // SPDX-License-Identifier: Apache-2.0 /// Iota System State Type Upgrade Guide -/// `IotaSystemState` is a thin wrapper around `IotaSystemStateInner` that provides a versioned interface. -/// The `IotaSystemState` object has a fixed ID 0x5, and the `IotaSystemStateInner` object is stored as a dynamic field. -/// There are a few different ways to upgrade the `IotaSystemStateInner` type: +/// `IotaSystemState` is a thin wrapper around `IotaSystemStateV1` that provides a versioned interface. +/// The `IotaSystemState` object has a fixed ID 0x5, and the `IotaSystemStateV1` object is stored as a dynamic field. +/// There are a few different ways to upgrade the `IotaSystemStateV1` type: /// /// The simplest and one that doesn't involve a real upgrade is to just add dynamic fields to the `extra_fields` field -/// of `IotaSystemStateInner` or any of its sub type. This is useful when we are in a rush, or making a small change, +/// of `IotaSystemStateV1` or any of its sub type. This is useful when we are in a rush, or making a small change, /// or still experimenting a new field. /// -/// To properly upgrade the `IotaSystemStateInner` type, we need to ship a new framework that does the following: -/// 1. Define a new `IotaSystemStateInner`type (e.g. `IotaSystemStateInnerV2`). -/// 2. Define a data migration function that migrates the old `IotaSystemStateInner` to the new one (i.e. IotaSystemStateInnerV2). -/// 3. Replace all uses of `IotaSystemStateInner` with `IotaSystemStateInnerV2` in both iota_system.move and iota_system_state_inner.move, +/// To properly upgrade the `IotaSystemStateV1` type, we need to ship a new framework that does the following: +/// 1. Define a new `IotaSystemState`type (e.g. `IotaSystemStateV2`). +/// 2. Define a data migration function that migrates the old (e.g. `IotaSystemStateV1`) to the new one (e.g. `IotaSystemStateV2`). +/// 3. Replace all uses of `IotaSystemStateV1` with `IotaSystemStateV2` in both iota_system.move and iota_system_state_inner.move, /// with the exception of the `iota_system_state_inner::create` function, which should always return the genesis type. /// 4. Inside `load_inner_maybe_upgrade` function, check the current version in the wrapper, and if it's not the latest version, /// call the data migration function to upgrade the inner object. Make sure to also update the version in the wrapper. /// A detailed example can be found in iota/tests/framework_upgrades/mock_iota_systems/shallow_upgrade. /// Along with the Move change, we also need to update the Rust code to support the new type. This includes: -/// 1. Define a new `IotaSystemStateInner` struct type that matches the new Move type, and implement the IotaSystemStateTrait. +/// 1. Define a new `IotaSystemState` struct type that matches the new Move type, and implement the `IotaSystemStateTrait`. /// 2. Update the `IotaSystemState` struct to include the new version as a new enum variant. /// 3. Update the `get_iota_system_state` function to handle the new version. /// To test that the upgrade will be successful, we need to modify `iota_system_state_production_upgrade_test` test in @@ -29,15 +29,15 @@ /// /// To upgrade Validator type, besides everything above, we also need to: /// 1. Define a new Validator type (e.g. ValidatorV2). -/// 2. Define a data migration function that migrates the old Validator to the new one (i.e. ValidatorV2). -/// 3. Replace all uses of Validator with ValidatorV2 except the genesis creation function. +/// 2. Define a data migration function that migrates the old ValidatorV1 to the new one (i.e. ValidatorV2). +/// 3. Replace all uses of ValidatorV1 with ValidatorV2 except the genesis creation function. /// 4. In validator_wrapper::upgrade_to_latest, check the current version in the wrapper, and if it's not the latest version, /// call the data migration function to upgrade it. /// In Rust, we also need to add a new case in `get_validator_from_table`. -/// Note that it is possible to upgrade IotaSystemStateInner without upgrading Validator, but not the other way around. -/// And when we only upgrade IotaSystemStateInner, the version of Validator in the wrapper will not be updated, and hence may become -/// inconsistent with the version of IotaSystemStateInner. This is fine as long as we don't use the Validator version to determine -/// the IotaSystemStateInner version, or vice versa. +/// Note that it is possible to upgrade IotaSystemStateV1 without upgrading ValidatorV1, but not the other way around. +/// And when we only upgrade IotaSystemStateV1, the version of ValidatorV1 in the wrapper will not be updated, and hence may become +/// inconsistent with the version of IotaSystemStateV1. This is fine as long as we don't use the ValidatorV1 version to determine +/// the IotaSystemStateV1 version, or vice versa. module iota_system::iota_system { use iota::balance::Balance; @@ -47,15 +47,15 @@ module iota_system::iota_system { use iota::iota::{IOTA, IotaTreasuryCap}; use iota::table::Table; use iota::timelock::SystemTimelockCap; - use iota_system::validator::Validator; + use iota_system::validator::ValidatorV1; use iota_system::validator_cap::UnverifiedValidatorOperationCap; - use iota_system::iota_system_state_inner::{Self, SystemParameters, IotaSystemStateInner, IotaSystemStateInnerV2}; + use iota_system::iota_system_state_inner::{Self, SystemParametersV1, IotaSystemStateV1}; use iota_system::staking_pool::PoolTokenExchangeRate; use iota::dynamic_field; use iota::vec_map::VecMap; #[test_only] use iota::balance; - #[test_only] use iota_system::validator_set::ValidatorSet; + #[test_only] use iota_system::validator_set::ValidatorSetV1; #[test_only] use iota::vec_set::VecSet; public struct IotaSystemState has key { @@ -75,11 +75,11 @@ module iota_system::iota_system { public(package) fun create( id: UID, iota_treasury_cap: IotaTreasuryCap, - validators: vector, + validators: vector, storage_fund: Balance, protocol_version: u64, epoch_start_timestamp_ms: u64, - parameters: SystemParameters, + parameters: SystemParametersV1, system_timelock_cap: SystemTimelockCap, ctx: &mut TxContext, ) { @@ -527,7 +527,7 @@ module iota_system::iota_system { ctx: &mut TxContext, ) : Balance { let self = load_system_state_mut(wrapper); - // Validator will make a special system call with sender set as 0x0. + // ValidatorV1 will make a special system call with sender set as 0x0. assert!(ctx.sender() == @0x0, ENotSystemAddress); let storage_rebate = self.advance_epoch( new_epoch, @@ -545,23 +545,16 @@ module iota_system::iota_system { storage_rebate } - fun load_system_state(self: &mut IotaSystemState): &IotaSystemStateInnerV2 { + fun load_system_state(self: &mut IotaSystemState): &IotaSystemStateV1 { load_inner_maybe_upgrade(self) } - fun load_system_state_mut(self: &mut IotaSystemState): &mut IotaSystemStateInnerV2 { + fun load_system_state_mut(self: &mut IotaSystemState): &mut IotaSystemStateV1 { load_inner_maybe_upgrade(self) } - fun load_inner_maybe_upgrade(self: &mut IotaSystemState): &mut IotaSystemStateInnerV2 { - if (self.version == 1) { - let v1: IotaSystemStateInner = dynamic_field::remove(&mut self.id, self.version); - let v2 = v1.v1_to_v2(); - self.version = 2; - dynamic_field::add(&mut self.id, self.version, v2); - }; - - let inner: &mut IotaSystemStateInnerV2 = dynamic_field::borrow_mut( + fun load_inner_maybe_upgrade(self: &mut IotaSystemState): &mut IotaSystemStateV1 { + let inner: &mut IotaSystemStateV1 = dynamic_field::borrow_mut( &mut self.id, self.version ); @@ -635,26 +628,26 @@ module iota_system::iota_system { #[test_only] /// Return the current validator set - public fun validators(wrapper: &mut IotaSystemState): &ValidatorSet { + public fun validators(wrapper: &mut IotaSystemState): &ValidatorSetV1 { let self = load_system_state(wrapper); self.validators() } #[test_only] /// Return the currently active validator by address - public fun active_validator_by_address(self: &mut IotaSystemState, validator_address: address): &Validator { + public fun active_validator_by_address(self: &mut IotaSystemState, validator_address: address): &ValidatorV1 { validators(self).get_active_validator_ref(validator_address) } #[test_only] /// Return the currently pending validator by address - public fun pending_validator_by_address(self: &mut IotaSystemState, validator_address: address): &Validator { + public fun pending_validator_by_address(self: &mut IotaSystemState, validator_address: address): &ValidatorV1 { validators(self).get_pending_validator_ref(validator_address) } #[test_only] /// Return the currently candidate validator by address - public fun candidate_validator_by_address(self: &mut IotaSystemState, validator_address: address): &Validator { + public fun candidate_validator_by_address(self: &mut IotaSystemState, validator_address: address): &ValidatorV1 { validators(self).get_candidate_validator_ref(validator_address) } diff --git a/crates/iota-framework/packages/iota-system/sources/iota_system_state_inner.move b/crates/iota-framework/packages/iota-system/sources/iota_system_state_inner.move index 18080109b30..ba74ebc9bf8 100644 --- a/crates/iota-framework/packages/iota-system/sources/iota_system_state_inner.move +++ b/crates/iota-framework/packages/iota-system/sources/iota_system_state_inner.move @@ -7,10 +7,10 @@ module iota_system::iota_system_state_inner { use iota::coin::Coin; use iota_system::staking_pool::StakedIota; use iota::iota::{IOTA, IotaTreasuryCap}; - use iota_system::validator::{Self, Validator}; - use iota_system::validator_set::{Self, ValidatorSet}; + use iota_system::validator::{Self, ValidatorV1}; + use iota_system::validator_set::{Self, ValidatorSetV1}; use iota_system::validator_cap::{UnverifiedValidatorOperationCap, ValidatorOperationCap}; - use iota_system::storage_fund::{Self, StorageFund}; + use iota_system::storage_fund::{Self, StorageFundV1}; use iota_system::staking_pool::PoolTokenExchangeRate; use iota::vec_map::{Self, VecMap}; use iota::vec_set::{Self, VecSet}; @@ -27,36 +27,7 @@ module iota_system::iota_system_state_inner { const SYSTEM_STATE_VERSION_V1: u64 = 1; /// A list of system config parameters. - public struct SystemParameters has store { - /// The duration of an epoch, in milliseconds. - epoch_duration_ms: u64, - - /// Maximum number of active validators at any moment. - /// We do not allow the number of validators in any epoch to go above this. - max_validator_count: u64, - - /// Lower-bound on the amount of stake required to become a validator. - min_validator_joining_stake: u64, - - /// Validators with stake amount below `validator_low_stake_threshold` are considered to - /// have low stake and will be escorted out of the validator set after being below this - /// threshold for more than `validator_low_stake_grace_period` number of epochs. - validator_low_stake_threshold: u64, - - /// Validators with stake below `validator_very_low_stake_threshold` will be removed - /// immediately at epoch change, no grace period. - validator_very_low_stake_threshold: u64, - - /// A validator can have stake below `validator_low_stake_threshold` - /// for this many epochs before being kicked out. - validator_low_stake_grace_period: u64, - - /// Any extra fields that's not defined statically. - extra_fields: Bag, - } - - /// Added min_validator_count. - public struct SystemParametersV2 has store { + public struct SystemParametersV1 has store { /// The duration of an epoch, in milliseconds. epoch_duration_ms: u64, @@ -88,71 +59,23 @@ module iota_system::iota_system_state_inner { } /// The top-level object containing all information of the Iota system. - public struct IotaSystemStateInner has store { + public struct IotaSystemStateV1 has store { /// The current epoch ID, starting from 0. epoch: u64, /// The current protocol version, starting from 1. protocol_version: u64, /// The current version of the system state data structure type. /// This is always the same as IotaSystemState.version. Keeping a copy here so that - /// we know what version it is by inspecting IotaSystemStateInner as well. + /// we know what version it is by inspecting IotaSystemStateV1 as well. system_state_version: u64, /// The IOTA's TreasuryCap. iota_treasury_cap: IotaTreasuryCap, /// Contains all information about the validators. - validators: ValidatorSet, + validators: ValidatorSetV1, /// The storage fund. - storage_fund: StorageFund, + storage_fund: StorageFundV1, /// A list of system config parameters. - parameters: SystemParameters, - /// The reference gas price for the current epoch. - reference_gas_price: u64, - /// A map storing the records of validator reporting each other. - /// There is an entry in the map for each validator that has been reported - /// at least once. The entry VecSet contains all the validators that reported - /// them. If a validator has never been reported they don't have an entry in this map. - /// This map persists across epoch: a peer continues being in a reported state until the - /// reporter doesn't explicitly remove their report. - /// Note that in case we want to support validator address change in future, - /// the reports should be based on validator ids - validator_report_records: VecMap>, - - /// Whether the system is running in a downgraded safe mode due to a non-recoverable bug. - /// This is set whenever we failed to execute advance_epoch, and ended up executing advance_epoch_safe_mode. - /// It can be reset once we are able to successfully execute advance_epoch. - /// The rest of the fields starting with `safe_mode_` are accmulated during safe mode - /// when advance_epoch_safe_mode is executed. They will eventually be processed once we - /// are out of safe mode. - safe_mode: bool, - safe_mode_storage_charges: Balance, - safe_mode_computation_rewards: Balance, - safe_mode_storage_rebates: u64, - safe_mode_non_refundable_storage_fee: u64, - - /// Unix timestamp of the current epoch start - epoch_start_timestamp_ms: u64, - /// Any extra fields that's not defined statically. - extra_fields: Bag, - } - - /// Uses SystemParametersV2 as the parameters. - public struct IotaSystemStateInnerV2 has store { - /// The current epoch ID, starting from 0. - epoch: u64, - /// The current protocol version, starting from 1. - protocol_version: u64, - /// The current version of the system state data structure type. - /// This is always the same as IotaSystemState.version. Keeping a copy here so that - /// we know what version it is by inspecting IotaSystemStateInner as well. - system_state_version: u64, - /// The IOTA's TreasuryCap. - iota_treasury_cap: IotaTreasuryCap, - /// Contains all information about the validators. - validators: ValidatorSet, - /// The storage fund. - storage_fund: StorageFund, - /// A list of system config parameters. - parameters: SystemParametersV2, + parameters: SystemParametersV1, /// The reference gas price for the current epoch. reference_gas_price: u64, /// A map storing the records of validator reporting each other. @@ -185,7 +108,7 @@ module iota_system::iota_system_state_inner { /// Event containing system-level epoch information, emitted during /// the epoch advancement transaction. - public struct SystemEpochInfoEvent has copy, drop { + public struct SystemEpochInfoEventV1 has copy, drop { epoch: u64, protocol_version: u64, reference_gas_price: u64, @@ -218,17 +141,17 @@ module iota_system::iota_system_state_inner { /// This function will be called only once in genesis. public(package) fun create( iota_treasury_cap: IotaTreasuryCap, - validators: vector, + validators: vector, initial_storage_fund: Balance, protocol_version: u64, epoch_start_timestamp_ms: u64, - parameters: SystemParameters, + parameters: SystemParametersV1, ctx: &mut TxContext, - ): IotaSystemStateInner { + ): IotaSystemStateV1 { let validators = validator_set::new(validators, ctx); let reference_gas_price = validators.derive_reference_gas_price(); // This type is fixed as it's created at genesis. It should not be updated during type upgrade. - let system_state = IotaSystemStateInner { + let system_state = IotaSystemStateV1 { epoch: 0, protocol_version, system_state_version: genesis_system_state_version(), @@ -252,16 +175,17 @@ module iota_system::iota_system_state_inner { public(package) fun create_system_parameters( epoch_duration_ms: u64, - // Validator committee parameters + // ValidatorV1 committee parameters max_validator_count: u64, min_validator_joining_stake: u64, validator_low_stake_threshold: u64, validator_very_low_stake_threshold: u64, validator_low_stake_grace_period: u64, ctx: &mut TxContext, - ): SystemParameters { - SystemParameters { + ): SystemParametersV1 { + SystemParametersV1 { epoch_duration_ms, + min_validator_count: 4, max_validator_count, min_validator_joining_stake, validator_low_stake_threshold, @@ -271,63 +195,6 @@ module iota_system::iota_system_state_inner { } } - public(package) fun v1_to_v2(self: IotaSystemStateInner): IotaSystemStateInnerV2 { - let IotaSystemStateInner { - epoch, - protocol_version, - system_state_version: _, - iota_treasury_cap, - validators, - storage_fund, - parameters, - reference_gas_price, - validator_report_records, - safe_mode, - safe_mode_storage_charges, - safe_mode_computation_rewards, - safe_mode_storage_rebates, - safe_mode_non_refundable_storage_fee, - epoch_start_timestamp_ms, - extra_fields: state_extra_fields, - } = self; - let SystemParameters { - epoch_duration_ms, - max_validator_count, - min_validator_joining_stake, - validator_low_stake_threshold, - validator_very_low_stake_threshold, - validator_low_stake_grace_period, - extra_fields: param_extra_fields, - } = parameters; - IotaSystemStateInnerV2 { - epoch, - protocol_version, - system_state_version: 2, - iota_treasury_cap, - validators, - storage_fund, - parameters: SystemParametersV2 { - epoch_duration_ms, - min_validator_count: 4, - max_validator_count, - min_validator_joining_stake, - validator_low_stake_threshold, - validator_very_low_stake_threshold, - validator_low_stake_grace_period, - extra_fields: param_extra_fields, - }, - reference_gas_price, - validator_report_records, - safe_mode, - safe_mode_storage_charges, - safe_mode_computation_rewards, - safe_mode_storage_rebates, - safe_mode_non_refundable_storage_fee, - epoch_start_timestamp_ms, - extra_fields: state_extra_fields - } - } - // ==== public(package) functions ==== /// Can be called by anyone who wishes to become a validator candidate and starts accuring delegated @@ -337,7 +204,7 @@ module iota_system::iota_system_state_inner { /// Note: `proof_of_possession` MUST be a valid signature using iota_address and authority_pubkey_bytes. /// To produce a valid PoP, run [fn test_proof_of_possession]. public(package) fun request_add_validator_candidate( - self: &mut IotaSystemStateInnerV2, + self: &mut IotaSystemStateV1, authority_pubkey_bytes: vector, network_pubkey_bytes: vector, protocol_pubkey_bytes: vector, @@ -377,7 +244,7 @@ module iota_system::iota_system_state_inner { /// Called by a validator candidate to remove themselves from the candidacy. After this call /// their staking pool becomes deactivate. public(package) fun request_remove_validator_candidate( - self: &mut IotaSystemStateInnerV2, + self: &mut IotaSystemStateV1, ctx: &mut TxContext, ) { self.validators.request_remove_validator_candidate(ctx); @@ -388,7 +255,7 @@ module iota_system::iota_system_state_inner { /// stake the validator has doesn't meet the min threshold, or if the number of new validators for the next /// epoch has already reached the maximum. public(package) fun request_add_validator( - self: &mut IotaSystemStateInnerV2, + self: &mut IotaSystemStateV1, ctx: &TxContext, ) { assert!( @@ -405,7 +272,7 @@ module iota_system::iota_system_state_inner { /// At the end of the epoch, the `validator` object will be returned to the iota_address /// of the validator. public(package) fun request_remove_validator( - self: &mut IotaSystemStateInnerV2, + self: &mut IotaSystemStateV1, ctx: &TxContext, ) { // Only check min validator condition if the current number of validators satisfy the constraint. @@ -424,7 +291,7 @@ module iota_system::iota_system_state_inner { /// A validator can call this function to submit a new gas price quote, to be /// used for the reference gas price calculation at the end of the epoch. public(package) fun request_set_gas_price( - self: &mut IotaSystemStateInnerV2, + self: &mut IotaSystemStateV1, cap: &UnverifiedValidatorOperationCap, new_gas_price: u64, ) { @@ -437,7 +304,7 @@ module iota_system::iota_system_state_inner { /// This function is used to set new gas price for candidate validators public(package) fun set_candidate_validator_gas_price( - self: &mut IotaSystemStateInnerV2, + self: &mut IotaSystemStateV1, cap: &UnverifiedValidatorOperationCap, new_gas_price: u64, ) { @@ -450,7 +317,7 @@ module iota_system::iota_system_state_inner { /// A validator can call this function to set a new commission rate, updated at the end of /// the epoch. public(package) fun request_set_commission_rate( - self: &mut IotaSystemStateInnerV2, + self: &mut IotaSystemStateV1, new_commission_rate: u64, ctx: &TxContext, ) { @@ -462,7 +329,7 @@ module iota_system::iota_system_state_inner { /// This function is used to set new commission rate for candidate validators public(package) fun set_candidate_validator_commission_rate( - self: &mut IotaSystemStateInnerV2, + self: &mut IotaSystemStateV1, new_commission_rate: u64, ctx: &TxContext, ) { @@ -472,7 +339,7 @@ module iota_system::iota_system_state_inner { /// Add stake to a validator's staking pool. public(package) fun request_add_stake( - self: &mut IotaSystemStateInnerV2, + self: &mut IotaSystemStateV1, stake: Coin, validator_address: address, ctx: &mut TxContext, @@ -486,7 +353,7 @@ module iota_system::iota_system_state_inner { /// Add stake to a validator's staking pool using multiple coins. public(package) fun request_add_stake_mul_coin( - self: &mut IotaSystemStateInnerV2, + self: &mut IotaSystemStateV1, stakes: vector>, stake_amount: option::Option, validator_address: address, @@ -498,7 +365,7 @@ module iota_system::iota_system_state_inner { /// Withdraw some portion of a stake from a validator's staking pool. public(package) fun request_withdraw_stake( - self: &mut IotaSystemStateInnerV2, + self: &mut IotaSystemStateV1, staked_iota: StakedIota, ctx: &TxContext, ) : Balance { @@ -512,7 +379,7 @@ module iota_system::iota_system_state_inner { /// 3. the cap object is still valid. /// This function is idempotent. public(package) fun report_validator( - self: &mut IotaSystemStateInnerV2, + self: &mut IotaSystemStateV1, cap: &UnverifiedValidatorOperationCap, reportee_addr: address, ) { @@ -529,7 +396,7 @@ module iota_system::iota_system_state_inner { /// 2. the sender has not previously reported the `reportee_addr`, or /// 3. the cap is not valid public(package) fun undo_report_validator( - self: &mut IotaSystemStateInnerV2, + self: &mut IotaSystemStateV1, cap: &UnverifiedValidatorOperationCap, reportee_addr: address, ) { @@ -576,7 +443,7 @@ module iota_system::iota_system_state_inner { /// Create a new `UnverifiedValidatorOperationCap`, transfer it to the /// validator and registers it. The original object is thus revoked. public(package) fun rotate_operation_cap( - self: &mut IotaSystemStateInnerV2, + self: &mut IotaSystemStateV1, ctx: &mut TxContext, ) { let validator = self.validators.get_validator_mut_with_ctx_including_candidates(ctx); @@ -585,7 +452,7 @@ module iota_system::iota_system_state_inner { /// Update a validator's name. public(package) fun update_validator_name( - self: &mut IotaSystemStateInnerV2, + self: &mut IotaSystemStateV1, name: vector, ctx: &TxContext, ) { @@ -596,7 +463,7 @@ module iota_system::iota_system_state_inner { /// Update a validator's description public(package) fun update_validator_description( - self: &mut IotaSystemStateInnerV2, + self: &mut IotaSystemStateV1, description: vector, ctx: &TxContext, ) { @@ -606,7 +473,7 @@ module iota_system::iota_system_state_inner { /// Update a validator's image url public(package) fun update_validator_image_url( - self: &mut IotaSystemStateInnerV2, + self: &mut IotaSystemStateV1, image_url: vector, ctx: &TxContext, ) { @@ -616,7 +483,7 @@ module iota_system::iota_system_state_inner { /// Update a validator's project url public(package) fun update_validator_project_url( - self: &mut IotaSystemStateInnerV2, + self: &mut IotaSystemStateV1, project_url: vector, ctx: &TxContext, ) { @@ -627,19 +494,19 @@ module iota_system::iota_system_state_inner { /// Update a validator's network address. /// The change will only take effects starting from the next epoch. public(package) fun update_validator_next_epoch_network_address( - self: &mut IotaSystemStateInnerV2, + self: &mut IotaSystemStateV1, network_address: vector, ctx: &TxContext, ) { let validator = self.validators.get_validator_mut_with_ctx(ctx); validator.update_next_epoch_network_address(network_address); - let validator :&Validator = validator; // Force immutability for the following call + let validator :&ValidatorV1 = validator; // Force immutability for the following call self.validators.assert_no_pending_or_active_duplicates(validator); } /// Update candidate validator's network address. public(package) fun update_candidate_validator_network_address( - self: &mut IotaSystemStateInnerV2, + self: &mut IotaSystemStateV1, network_address: vector, ctx: &TxContext, ) { @@ -650,19 +517,19 @@ module iota_system::iota_system_state_inner { /// Update a validator's p2p address. /// The change will only take effects starting from the next epoch. public(package) fun update_validator_next_epoch_p2p_address( - self: &mut IotaSystemStateInnerV2, + self: &mut IotaSystemStateV1, p2p_address: vector, ctx: &TxContext, ) { let validator = self.validators.get_validator_mut_with_ctx(ctx); validator.update_next_epoch_p2p_address(p2p_address); - let validator :&Validator = validator; // Force immutability for the following call + let validator :&ValidatorV1 = validator; // Force immutability for the following call self.validators.assert_no_pending_or_active_duplicates(validator); } /// Update candidate validator's p2p address. public(package) fun update_candidate_validator_p2p_address( - self: &mut IotaSystemStateInnerV2, + self: &mut IotaSystemStateV1, p2p_address: vector, ctx: &TxContext, ) { @@ -673,7 +540,7 @@ module iota_system::iota_system_state_inner { /// Update a validator's primary address. /// The change will only take effects starting from the next epoch. public(package) fun update_validator_next_epoch_primary_address( - self: &mut IotaSystemStateInnerV2, + self: &mut IotaSystemStateV1, primary_address: vector, ctx: &TxContext, ) { @@ -683,7 +550,7 @@ module iota_system::iota_system_state_inner { /// Update candidate validator's primary address. public(package) fun update_candidate_validator_primary_address( - self: &mut IotaSystemStateInnerV2, + self: &mut IotaSystemStateV1, primary_address: vector, ctx: &TxContext, ) { @@ -694,20 +561,20 @@ module iota_system::iota_system_state_inner { /// Update a validator's public key of authority key and proof of possession. /// The change will only take effects starting from the next epoch. public(package) fun update_validator_next_epoch_authority_pubkey( - self: &mut IotaSystemStateInnerV2, + self: &mut IotaSystemStateV1, authority_pubkey: vector, proof_of_possession: vector, ctx: &TxContext, ) { let validator = self.validators.get_validator_mut_with_ctx(ctx); validator.update_next_epoch_authority_pubkey(authority_pubkey, proof_of_possession); - let validator :&Validator = validator; // Force immutability for the following call + let validator :&ValidatorV1 = validator; // Force immutability for the following call self.validators.assert_no_pending_or_active_duplicates(validator); } /// Update candidate validator's public key of authority key and proof of possession. public(package) fun update_candidate_validator_authority_pubkey( - self: &mut IotaSystemStateInnerV2, + self: &mut IotaSystemStateV1, authority_pubkey: vector, proof_of_possession: vector, ctx: &TxContext, @@ -719,19 +586,19 @@ module iota_system::iota_system_state_inner { /// Update a validator's public key of protocol key. /// The change will only take effects starting from the next epoch. public(package) fun update_validator_next_epoch_protocol_pubkey( - self: &mut IotaSystemStateInnerV2, + self: &mut IotaSystemStateV1, protocol_pubkey: vector, ctx: &TxContext, ) { let validator = self.validators.get_validator_mut_with_ctx(ctx); validator.update_next_epoch_protocol_pubkey(protocol_pubkey); - let validator :&Validator = validator; // Force immutability for the following call + let validator :&ValidatorV1 = validator; // Force immutability for the following call self.validators.assert_no_pending_or_active_duplicates(validator); } /// Update candidate validator's public key of protocol key. public(package) fun update_candidate_validator_protocol_pubkey( - self: &mut IotaSystemStateInnerV2, + self: &mut IotaSystemStateV1, protocol_pubkey: vector, ctx: &TxContext, ) { @@ -742,19 +609,19 @@ module iota_system::iota_system_state_inner { /// Update a validator's public key of network key. /// The change will only take effects starting from the next epoch. public(package) fun update_validator_next_epoch_network_pubkey( - self: &mut IotaSystemStateInnerV2, + self: &mut IotaSystemStateV1, network_pubkey: vector, ctx: &TxContext, ) { let validator = self.validators.get_validator_mut_with_ctx(ctx); validator.update_next_epoch_network_pubkey(network_pubkey); - let validator :&Validator = validator; // Force immutability for the following call + let validator :&ValidatorV1 = validator; // Force immutability for the following call self.validators.assert_no_pending_or_active_duplicates(validator); } /// Update candidate validator's public key of network key. public(package) fun update_candidate_validator_network_pubkey( - self: &mut IotaSystemStateInnerV2, + self: &mut IotaSystemStateV1, network_pubkey: vector, ctx: &TxContext, ) { @@ -773,7 +640,7 @@ module iota_system::iota_system_state_inner { /// 5. Burn any leftover rewards. /// 6. Update all validators. public(package) fun advance_epoch( - self: &mut IotaSystemStateInnerV2, + self: &mut IotaSystemStateV1, new_epoch: u64, next_protocol_version: u64, validator_target_reward: u64, @@ -851,7 +718,7 @@ module iota_system::iota_system_state_inner { ); event::emit( - SystemEpochInfoEvent { + SystemEpochInfoEventV1 { epoch: self.epoch, protocol_version: self.protocol_version, reference_gas_price: self.reference_gas_price, @@ -902,15 +769,15 @@ module iota_system::iota_system_state_inner { /// Return the current epoch number. Useful for applications that need a coarse-grained concept of time, /// since epochs are ever-increasing and epoch changes are intended to happen every 24 hours. - public(package) fun epoch(self: &IotaSystemStateInnerV2): u64 { + public(package) fun epoch(self: &IotaSystemStateV1): u64 { self.epoch } - public(package) fun protocol_version(self: &IotaSystemStateInnerV2): u64 { + public(package) fun protocol_version(self: &IotaSystemStateV1): u64 { self.protocol_version } - public(package) fun system_state_version(self: &IotaSystemStateInnerV2): u64 { + public(package) fun system_state_version(self: &IotaSystemStateV1): u64 { self.system_state_version } @@ -921,19 +788,19 @@ module iota_system::iota_system_state_inner { } /// Returns unix timestamp of the start of current epoch - public(package) fun epoch_start_timestamp_ms(self: &IotaSystemStateInnerV2): u64 { + public(package) fun epoch_start_timestamp_ms(self: &IotaSystemStateV1): u64 { self.epoch_start_timestamp_ms } /// Returns the total amount staked with `validator_addr`. /// Aborts if `validator_addr` is not an active validator. - public(package) fun validator_stake_amount(self: &IotaSystemStateInnerV2, validator_addr: address): u64 { + public(package) fun validator_stake_amount(self: &IotaSystemStateV1, validator_addr: address): u64 { self.validators.validator_total_stake_amount(validator_addr) } /// Returns the voting power for `validator_addr`. /// Aborts if `validator_addr` is not an active validator. - public(package) fun active_validator_voting_powers(self: &IotaSystemStateInnerV2): VecMap { + public(package) fun active_validator_voting_powers(self: &IotaSystemStateV1): VecMap { let mut active_validators = active_validator_addresses(self); let mut voting_powers = vec_map::empty(); while (!vector::is_empty(&active_validators)) { @@ -946,24 +813,24 @@ module iota_system::iota_system_state_inner { /// Returns the staking pool id of a given validator. /// Aborts if `validator_addr` is not an active validator. - public(package) fun validator_staking_pool_id(self: &IotaSystemStateInnerV2, validator_addr: address): ID { + public(package) fun validator_staking_pool_id(self: &IotaSystemStateV1, validator_addr: address): ID { self.validators.validator_staking_pool_id(validator_addr) } /// Returns reference to the staking pool mappings that map pool ids to active validator addresses - public(package) fun validator_staking_pool_mappings(self: &IotaSystemStateInnerV2): &Table { + public(package) fun validator_staking_pool_mappings(self: &IotaSystemStateV1): &Table { self.validators.staking_pool_mappings() } /// Returns the total iota supply. - public(package) fun get_total_iota_supply(self: &IotaSystemStateInnerV2): u64 { + public(package) fun get_total_iota_supply(self: &IotaSystemStateV1): u64 { self.iota_treasury_cap.total_supply() } /// Returns all the validators who are currently reporting `addr` - public(package) fun get_reporters_of(self: &IotaSystemStateInnerV2, addr: address): VecSet
{ + public(package) fun get_reporters_of(self: &IotaSystemStateV1, addr: address): VecSet
{ if (self.validator_report_records.contains(&addr)) { self.validator_report_records[&addr] @@ -972,23 +839,23 @@ module iota_system::iota_system_state_inner { } } - public(package) fun get_storage_fund_total_balance(self: &IotaSystemStateInnerV2): u64 { + public(package) fun get_storage_fund_total_balance(self: &IotaSystemStateV1): u64 { self.storage_fund.total_balance() } - public(package) fun get_storage_fund_object_rebates(self: &IotaSystemStateInnerV2): u64 { + public(package) fun get_storage_fund_object_rebates(self: &IotaSystemStateV1): u64 { self.storage_fund.total_object_storage_rebates() } public(package) fun pool_exchange_rates( - self: &mut IotaSystemStateInnerV2, + self: &mut IotaSystemStateV1, pool_id: &ID ): &Table { let validators = &mut self.validators; validators.pool_exchange_rates(pool_id) } - public(package) fun active_validator_addresses(self: &IotaSystemStateInnerV2): vector
{ + public(package) fun active_validator_addresses(self: &IotaSystemStateV1): vector
{ let validator_set = &self.validators; validator_set.active_validator_addresses() } @@ -1018,36 +885,36 @@ module iota_system::iota_system_state_inner { #[test_only] /// Return the current validator set - public(package) fun validators(self: &IotaSystemStateInnerV2): &ValidatorSet { + public(package) fun validators(self: &IotaSystemStateV1): &ValidatorSetV1 { &self.validators } #[test_only] /// Return the currently active validator by address - public(package) fun active_validator_by_address(self: &IotaSystemStateInnerV2, validator_address: address): &Validator { + public(package) fun active_validator_by_address(self: &IotaSystemStateV1, validator_address: address): &ValidatorV1 { self.validators().get_active_validator_ref(validator_address) } #[test_only] /// Return the currently pending validator by address - public(package) fun pending_validator_by_address(self: &IotaSystemStateInnerV2, validator_address: address): &Validator { + public(package) fun pending_validator_by_address(self: &IotaSystemStateV1, validator_address: address): &ValidatorV1 { self.validators().get_pending_validator_ref(validator_address) } #[test_only] /// Return the currently candidate validator by address - public(package) fun candidate_validator_by_address(self: &IotaSystemStateInnerV2, validator_address: address): &Validator { + public(package) fun candidate_validator_by_address(self: &IotaSystemStateV1, validator_address: address): &ValidatorV1 { validators(self).get_candidate_validator_ref(validator_address) } #[test_only] - public(package) fun set_epoch_for_testing(self: &mut IotaSystemStateInnerV2, epoch_num: u64) { + public(package) fun set_epoch_for_testing(self: &mut IotaSystemStateV1, epoch_num: u64) { self.epoch = epoch_num } #[test_only] public(package) fun request_add_validator_for_testing( - self: &mut IotaSystemStateInnerV2, + self: &mut IotaSystemStateV1, min_joining_stake_for_testing: u64, ctx: &TxContext, ) { @@ -1064,7 +931,7 @@ module iota_system::iota_system_state_inner { // in the process. #[test_only] public(package) fun request_add_validator_candidate_for_testing( - self: &mut IotaSystemStateInnerV2, + self: &mut IotaSystemStateV1, pubkey_bytes: vector, network_pubkey_bytes: vector, protocol_pubkey_bytes: vector, diff --git a/crates/iota-framework/packages/iota-system/sources/staking_pool.move b/crates/iota-framework/packages/iota-system/sources/staking_pool.move index 6e41baee1f1..4c1d1123f04 100644 --- a/crates/iota-framework/packages/iota-system/sources/staking_pool.move +++ b/crates/iota-framework/packages/iota-system/sources/staking_pool.move @@ -34,7 +34,7 @@ module iota_system::staking_pool { const EStakedIotaBelowThreshold: u64 = 18; /// A staking pool embedded in each validator struct in the system state object. - public struct StakingPool has key, store { + public struct StakingPoolV1 has key, store { id: UID, /// The epoch at which this pool became active. /// The value is `None` if the pool is pre-active and `Some()` if active or inactive. @@ -84,9 +84,9 @@ module iota_system::staking_pool { // ==== initializer ==== /// Create a new, empty staking pool. - public(package) fun new(ctx: &mut TxContext) : StakingPool { + public(package) fun new(ctx: &mut TxContext) : StakingPoolV1 { let exchange_rates = table::new(ctx); - StakingPool { + StakingPoolV1 { id: object::new(ctx), activation_epoch: option::none(), deactivation_epoch: option::none(), @@ -105,7 +105,7 @@ module iota_system::staking_pool { /// Request to stake to a staking pool. The stake starts counting at the beginning of the next epoch, public(package) fun request_add_stake( - pool: &mut StakingPool, + pool: &mut StakingPoolV1, stake: Balance, stake_activation_epoch: u64, ctx: &mut TxContext @@ -127,7 +127,7 @@ module iota_system::staking_pool { /// Both the principal and corresponding rewards in IOTA are withdrawn. /// A proportional amount of pool token withdraw is recorded and processed at epoch change time. public(package) fun request_withdraw_stake( - pool: &mut StakingPool, + pool: &mut StakingPoolV1, staked_iota: StakedIota, ctx: &TxContext ) : Balance { @@ -163,7 +163,7 @@ module iota_system::staking_pool { /// tokens using exchange rate at staking epoch. /// Returns values are amount of pool tokens withdrawn and withdrawn principal portion of IOTA. public(package) fun withdraw_from_principal( - pool: &StakingPool, + pool: &StakingPoolV1, staked_iota: StakedIota, ) : (u64, Balance) { @@ -200,12 +200,12 @@ module iota_system::staking_pool { // ==== functions called at epoch boundaries === /// Called at epoch advancement times to add rewards (in IOTA) to the staking pool. - public(package) fun deposit_rewards(pool: &mut StakingPool, rewards: Balance) { + public(package) fun deposit_rewards(pool: &mut StakingPoolV1, rewards: Balance) { pool.iota_balance = pool.iota_balance + rewards.value(); pool.rewards_pool.join(rewards); } - public(package) fun process_pending_stakes_and_withdraws(pool: &mut StakingPool, ctx: &TxContext) { + public(package) fun process_pending_stakes_and_withdraws(pool: &mut StakingPoolV1, ctx: &TxContext) { let new_epoch = ctx.epoch() + 1; process_pending_stake_withdraw(pool); process_pending_stake(pool); @@ -218,7 +218,7 @@ module iota_system::staking_pool { /// Called at epoch boundaries to process pending stake withdraws requested during the epoch. /// Also called immediately upon withdrawal if the pool is inactive. - fun process_pending_stake_withdraw(pool: &mut StakingPool) { + fun process_pending_stake_withdraw(pool: &mut StakingPoolV1) { pool.iota_balance = pool.iota_balance - pool.pending_total_iota_withdraw; pool.pool_token_balance = pool.pool_token_balance - pool.pending_pool_token_withdraw; pool.pending_total_iota_withdraw = 0; @@ -226,7 +226,7 @@ module iota_system::staking_pool { } /// Called at epoch boundaries to process the pending stake. - public(package) fun process_pending_stake(pool: &mut StakingPool) { + public(package) fun process_pending_stake(pool: &mut StakingPoolV1) { // Use the most up to date exchange rate with the rewards deposited and withdraws effectuated. let latest_exchange_rate = PoolTokenExchangeRate { iota_amount: pool.iota_balance, pool_token_amount: pool.pool_token_balance }; @@ -243,7 +243,7 @@ module iota_system::staking_pool { /// 3. Withdraws the rewards portion from the rewards pool at the current exchange rate. We only withdraw the rewards /// portion because the principal portion was already taken out of the staker's self custodied StakedIota. fun withdraw_rewards( - pool: &mut StakingPool, + pool: &mut StakingPoolV1, principal_withdraw_amount: u64, pool_token_withdraw_amount: u64, epoch: u64, @@ -264,7 +264,7 @@ module iota_system::staking_pool { // ==== preactive pool related ==== /// Called by `validator` module to activate a staking pool. - public(package) fun activate_staking_pool(pool: &mut StakingPool, activation_epoch: u64) { + public(package) fun activate_staking_pool(pool: &mut StakingPoolV1, activation_epoch: u64) { // Add the initial exchange rate to the table. pool.exchange_rates.add( activation_epoch, @@ -282,7 +282,7 @@ module iota_system::staking_pool { /// Deactivate a staking pool by setting the `deactivation_epoch`. After /// this pool deactivation, the pool stops earning rewards. Only stake /// withdraws can be made to the pool. - public(package) fun deactivate_staking_pool(pool: &mut StakingPool, deactivation_epoch: u64) { + public(package) fun deactivate_staking_pool(pool: &mut StakingPoolV1, deactivation_epoch: u64) { // We can't deactivate an already deactivated pool. assert!(!is_inactive(pool), EDeactivationOfInactivePool); pool.deactivation_epoch = option::some(deactivation_epoch); @@ -290,7 +290,7 @@ module iota_system::staking_pool { // ==== getters and misc utility functions ==== - public fun iota_balance(pool: &StakingPool): u64 { pool.iota_balance } + public fun iota_balance(pool: &StakingPoolV1): u64 { pool.iota_balance } public fun pool_id(staked_iota: &StakedIota): ID { staked_iota.pool_id } @@ -304,12 +304,12 @@ module iota_system::staking_pool { } /// Returns true if the input staking pool is preactive. - public fun is_preactive(pool: &StakingPool): bool{ + public fun is_preactive(pool: &StakingPoolV1): bool{ pool.activation_epoch.is_none() } /// Returns true if the input staking pool is inactive. - public fun is_inactive(pool: &StakingPool): bool { + public fun is_inactive(pool: &StakingPoolV1): bool { pool.deactivation_epoch.is_some() } @@ -364,7 +364,7 @@ module iota_system::staking_pool { (self.stake_activation_epoch == other.stake_activation_epoch) } - public fun pool_token_exchange_rate_at_epoch(pool: &StakingPool, epoch: u64): PoolTokenExchangeRate { + public fun pool_token_exchange_rate_at_epoch(pool: &StakingPoolV1, epoch: u64): PoolTokenExchangeRate { // If the pool is preactive then the exchange rate is always 1:1. if (is_preactive_at_epoch(pool, epoch)) { return initial_exchange_rate() @@ -385,16 +385,16 @@ module iota_system::staking_pool { } /// Returns the total value of the pending staking requests for this staking pool. - public fun pending_stake_amount(staking_pool: &StakingPool): u64 { + public fun pending_stake_amount(staking_pool: &StakingPoolV1): u64 { staking_pool.pending_stake } /// Returns the total withdrawal from the staking pool this epoch. - public fun pending_stake_withdraw_amount(staking_pool: &StakingPool): u64 { + public fun pending_stake_withdraw_amount(staking_pool: &StakingPoolV1): u64 { staking_pool.pending_total_iota_withdraw } - public(package) fun exchange_rates(pool: &StakingPool): &Table { + public(package) fun exchange_rates(pool: &StakingPoolV1): &Table { &pool.exchange_rates } @@ -407,7 +407,7 @@ module iota_system::staking_pool { } /// Returns true if the provided staking pool is preactive at the provided epoch. - fun is_preactive_at_epoch(pool: &StakingPool, epoch: u64): bool{ + fun is_preactive_at_epoch(pool: &StakingPoolV1, epoch: u64): bool{ // Either the pool is currently preactive or the pool's starting epoch is later than the provided epoch. is_preactive(pool) || (*pool.activation_epoch.borrow() > epoch) } @@ -440,7 +440,7 @@ module iota_system::staking_pool { PoolTokenExchangeRate { iota_amount: 0, pool_token_amount: 0 } } - fun check_balance_invariants(pool: &StakingPool, epoch: u64) { + fun check_balance_invariants(pool: &StakingPoolV1, epoch: u64) { let exchange_rate = pool_token_exchange_rate_at_epoch(pool, epoch); // check that the pool token balance and iota balance ratio matches the exchange rate stored. let expected = get_token_amount(&exchange_rate, pool.iota_balance); @@ -453,7 +453,7 @@ module iota_system::staking_pool { // Given the `staked_iota` receipt calculate the current rewards (in terms of IOTA) for it. #[test_only] public fun calculate_rewards( - pool: &StakingPool, + pool: &StakingPoolV1, staked_iota: &StakedIota, current_epoch: u64, ): u64 { diff --git a/crates/iota-framework/packages/iota-system/sources/storage_fund.move b/crates/iota-framework/packages/iota-system/sources/storage_fund.move index af347f40594..c25a5ebeabf 100644 --- a/crates/iota-framework/packages/iota-system/sources/storage_fund.move +++ b/crates/iota-framework/packages/iota-system/sources/storage_fund.move @@ -14,14 +14,14 @@ module iota_system::storage_fund { /// the non-refundable portion taken out and put into `non_refundable_balance`. /// - `non_refundable_balance` contains any remaining inflow of the storage fund that should not /// be taken out of the fund. - public struct StorageFund has store { + public struct StorageFundV1 has store { total_object_storage_rebates: Balance, non_refundable_balance: Balance, } /// Called by `iota_system` at genesis time. - public(package) fun new(initial_fund: Balance) : StorageFund { - StorageFund { + public(package) fun new(initial_fund: Balance) : StorageFundV1 { + StorageFundV1 { // At the beginning there's no object in the storage yet total_object_storage_rebates: balance::zero(), non_refundable_balance: initial_fund, @@ -30,7 +30,7 @@ module iota_system::storage_fund { /// Called by `iota_system` at epoch change times to process the inflows and outflows of storage fund. public(package) fun advance_epoch( - self: &mut StorageFund, + self: &mut StorageFundV1, storage_charges: Balance, storage_rebate_amount: u64, non_refundable_storage_fee_amount: u64, @@ -53,11 +53,11 @@ module iota_system::storage_fund { storage_rebate } - public fun total_object_storage_rebates(self: &StorageFund): u64 { + public fun total_object_storage_rebates(self: &StorageFundV1): u64 { self.total_object_storage_rebates.value() } - public fun total_balance(self: &StorageFund): u64 { + public fun total_balance(self: &StorageFundV1): u64 { self.total_object_storage_rebates.value() + self.non_refundable_balance.value() } } diff --git a/crates/iota-framework/packages/iota-system/sources/timelocked_staking.move b/crates/iota-framework/packages/iota-system/sources/timelocked_staking.move index abc3e10a107..c5cd343cb39 100644 --- a/crates/iota-framework/packages/iota-system/sources/timelocked_staking.move +++ b/crates/iota-framework/packages/iota-system/sources/timelocked_staking.move @@ -11,7 +11,7 @@ module iota_system::timelocked_staking { use iota_system::iota_system::{IotaSystemState}; use iota_system::staking_pool::StakedIota; - use iota_system::validator::{Validator}; + use iota_system::validator::{ValidatorV1}; /// For when trying to stake an expired time-locked balance. const ETimeLockShouldNotBeExpired: u64 = 0; @@ -324,7 +324,7 @@ module iota_system::timelocked_staking { /// Request to add timelocked stake to the validator's staking pool at genesis public(package) fun request_add_stake_at_genesis( - validator: &mut Validator, + validator: &mut ValidatorV1, stake: Balance, staker_address: address, expiration_timestamp_ms: u64, diff --git a/crates/iota-framework/packages/iota-system/sources/validator.move b/crates/iota-framework/packages/iota-system/sources/validator.move index d89ea35b59f..4b4b7175ccf 100644 --- a/crates/iota-framework/packages/iota-system/sources/validator.move +++ b/crates/iota-framework/packages/iota-system/sources/validator.move @@ -9,7 +9,7 @@ module iota_system::validator { use iota::balance::Balance; use iota::iota::IOTA; use iota_system::validator_cap::{Self, ValidatorOperationCap}; - use iota_system::staking_pool::{Self, PoolTokenExchangeRate, StakedIota, StakingPool}; + use iota_system::staking_pool::{Self, PoolTokenExchangeRate, StakedIota, StakingPoolV1}; use std::string::String; use iota::url::Url; use iota::url; @@ -71,8 +71,8 @@ module iota_system::validator { /// Max gas price a validator can set is 100K NANOS. const MAX_VALIDATOR_GAS_PRICE: u64 = 100_000; - public struct ValidatorMetadata has store { - /// The Iota Address of the validator. This is the sender that created the Validator object, + public struct ValidatorMetadataV1 has store { + /// The Iota Address of the validator. This is the sender that created the ValidatorV1 object, /// and also the address to send validator/coins to during withdraws. iota_address: address, /// The public key bytes corresponding to the private key that the validator @@ -112,9 +112,9 @@ module iota_system::validator { extra_fields: Bag, } - public struct Validator has store { + public struct ValidatorV1 has store { /// Summary of the validator. - metadata: ValidatorMetadata, + metadata: ValidatorMetadataV1, /// The voting power of this validator, which might be different from its /// stake amount. voting_power: u64, @@ -123,7 +123,7 @@ module iota_system::validator { /// Gas price quote, updated only at end of epoch. gas_price: u64, /// Staking pool for this validator. - staking_pool: StakingPool, + staking_pool: StakingPoolV1, /// Commission rate of the validator, in basis point. commission_rate: u64, /// Total amount of stake that would be active in the next epoch. @@ -170,8 +170,8 @@ module iota_system::validator { p2p_address: String, primary_address: String, extra_fields: Bag, - ): ValidatorMetadata { - let metadata = ValidatorMetadata { + ): ValidatorMetadataV1 { + let metadata = ValidatorMetadataV1 { iota_address, authority_pubkey_bytes, network_pubkey_bytes, @@ -212,7 +212,7 @@ module iota_system::validator { gas_price: u64, commission_rate: u64, ctx: &mut TxContext - ): Validator { + ): ValidatorV1 { assert!( net_address.length() <= MAX_VALIDATOR_METADATA_LENGTH && p2p_address.length() <= MAX_VALIDATOR_METADATA_LENGTH @@ -254,23 +254,23 @@ module iota_system::validator { } /// Deactivate this validator's staking pool - public(package) fun deactivate(self: &mut Validator, deactivation_epoch: u64) { + public(package) fun deactivate(self: &mut ValidatorV1, deactivation_epoch: u64) { self.staking_pool.deactivate_staking_pool(deactivation_epoch) } - public(package) fun activate(self: &mut Validator, activation_epoch: u64) { + public(package) fun activate(self: &mut ValidatorV1, activation_epoch: u64) { self.staking_pool.activate_staking_pool(activation_epoch); } /// Process pending stake and pending withdraws, and update the gas price. - public(package) fun adjust_stake_and_gas_price(self: &mut Validator) { + public(package) fun adjust_stake_and_gas_price(self: &mut ValidatorV1) { self.gas_price = self.next_epoch_gas_price; self.commission_rate = self.next_epoch_commission_rate; } /// Request to add stake to the validator's staking pool, processed at the end of the epoch. public(package) fun request_add_stake( - self: &mut Validator, + self: &mut ValidatorV1, stake: Balance, staker_address: address, ctx: &mut TxContext, @@ -298,7 +298,7 @@ module iota_system::validator { /// Request to add stake to the validator's staking pool at genesis public(package) fun request_add_stake_at_genesis( - self: &mut Validator, + self: &mut ValidatorV1, stake: Balance, staker_address: address, ctx: &mut TxContext, @@ -314,7 +314,7 @@ module iota_system::validator { /// Internal request to add stake to the validator's staking pool at genesis. /// Returns a StakedIota public(package) fun request_add_stake_at_genesis_with_receipt( - self: &mut Validator, + self: &mut ValidatorV1, stake: Balance, ctx: &mut TxContext, ) : StakedIota { @@ -337,7 +337,7 @@ module iota_system::validator { /// Request to withdraw stake from the validator's staking pool, processed at the end of the epoch. public(package) fun request_withdraw_stake( - self: &mut Validator, + self: &mut ValidatorV1, staked_iota: StakedIota, ctx: &TxContext, ) : Balance { @@ -364,7 +364,7 @@ module iota_system::validator { /// Request to set new gas price for the next epoch. /// Need to present a `ValidatorOperationCap`. public(package) fun request_set_gas_price( - self: &mut Validator, + self: &mut ValidatorV1, verified_cap: ValidatorOperationCap, new_price: u64, ) { @@ -376,7 +376,7 @@ module iota_system::validator { /// Set new gas price for the candidate validator. public(package) fun set_candidate_gas_price( - self: &mut Validator, + self: &mut ValidatorV1, verified_cap: ValidatorOperationCap, new_price: u64 ) { @@ -389,174 +389,174 @@ module iota_system::validator { } /// Request to set new commission rate for the next epoch. - public(package) fun request_set_commission_rate(self: &mut Validator, new_commission_rate: u64) { + public(package) fun request_set_commission_rate(self: &mut ValidatorV1, new_commission_rate: u64) { assert!(new_commission_rate <= MAX_COMMISSION_RATE, ECommissionRateTooHigh); self.next_epoch_commission_rate = new_commission_rate; } /// Set new commission rate for the candidate validator. - public(package) fun set_candidate_commission_rate(self: &mut Validator, new_commission_rate: u64) { + public(package) fun set_candidate_commission_rate(self: &mut ValidatorV1, new_commission_rate: u64) { assert!(is_preactive(self), ENotValidatorCandidate); assert!(new_commission_rate <= MAX_COMMISSION_RATE, ECommissionRateTooHigh); self.commission_rate = new_commission_rate; } /// Deposit stakes rewards into the validator's staking pool, called at the end of the epoch. - public(package) fun deposit_stake_rewards(self: &mut Validator, reward: Balance) { + public(package) fun deposit_stake_rewards(self: &mut ValidatorV1, reward: Balance) { self.next_epoch_stake = self.next_epoch_stake + reward.value(); self.staking_pool.deposit_rewards(reward); } /// Process pending stakes and withdraws, called at the end of the epoch. - public(package) fun process_pending_stakes_and_withdraws(self: &mut Validator, ctx: &TxContext) { + public(package) fun process_pending_stakes_and_withdraws(self: &mut ValidatorV1, ctx: &TxContext) { self.staking_pool.process_pending_stakes_and_withdraws(ctx); assert!(stake_amount(self) == self.next_epoch_stake, EInvalidStakeAmount); } /// Returns true if the validator is preactive. - public fun is_preactive(self: &Validator): bool { + public fun is_preactive(self: &ValidatorV1): bool { self.staking_pool.is_preactive() } - public fun metadata(self: &Validator): &ValidatorMetadata { + public fun metadata(self: &ValidatorV1): &ValidatorMetadataV1 { &self.metadata } - public fun iota_address(self: &Validator): address { + public fun iota_address(self: &ValidatorV1): address { self.metadata.iota_address } - public fun name(self: &Validator): &String { + public fun name(self: &ValidatorV1): &String { &self.metadata.name } - public fun description(self: &Validator): &String { + public fun description(self: &ValidatorV1): &String { &self.metadata.description } - public fun image_url(self: &Validator): &Url { + public fun image_url(self: &ValidatorV1): &Url { &self.metadata.image_url } - public fun project_url(self: &Validator): &Url { + public fun project_url(self: &ValidatorV1): &Url { &self.metadata.project_url } - public fun network_address(self: &Validator): &String { + public fun network_address(self: &ValidatorV1): &String { &self.metadata.net_address } - public fun p2p_address(self: &Validator): &String { + public fun p2p_address(self: &ValidatorV1): &String { &self.metadata.p2p_address } - public fun primary_address(self: &Validator): &String { + public fun primary_address(self: &ValidatorV1): &String { &self.metadata.primary_address } - public fun authority_pubkey_bytes(self: &Validator): &vector { + public fun authority_pubkey_bytes(self: &ValidatorV1): &vector { &self.metadata.authority_pubkey_bytes } - public fun proof_of_possession(self: &Validator): &vector { + public fun proof_of_possession(self: &ValidatorV1): &vector { &self.metadata.proof_of_possession } - public fun network_pubkey_bytes(self: &Validator): &vector { + public fun network_pubkey_bytes(self: &ValidatorV1): &vector { &self.metadata.network_pubkey_bytes } - public fun protocol_pubkey_bytes(self: &Validator): &vector { + public fun protocol_pubkey_bytes(self: &ValidatorV1): &vector { &self.metadata.protocol_pubkey_bytes } - public fun next_epoch_network_address(self: &Validator): &Option { + public fun next_epoch_network_address(self: &ValidatorV1): &Option { &self.metadata.next_epoch_net_address } - public fun next_epoch_p2p_address(self: &Validator): &Option { + public fun next_epoch_p2p_address(self: &ValidatorV1): &Option { &self.metadata.next_epoch_p2p_address } - public fun next_epoch_primary_address(self: &Validator): &Option { + public fun next_epoch_primary_address(self: &ValidatorV1): &Option { &self.metadata.next_epoch_primary_address } - public fun next_epoch_authority_pubkey_bytes(self: &Validator): &Option> { + public fun next_epoch_authority_pubkey_bytes(self: &ValidatorV1): &Option> { &self.metadata.next_epoch_authority_pubkey_bytes } - public fun next_epoch_proof_of_possession(self: &Validator): &Option> { + public fun next_epoch_proof_of_possession(self: &ValidatorV1): &Option> { &self.metadata.next_epoch_proof_of_possession } - public fun next_epoch_network_pubkey_bytes(self: &Validator): &Option> { + public fun next_epoch_network_pubkey_bytes(self: &ValidatorV1): &Option> { &self.metadata.next_epoch_network_pubkey_bytes } - public fun next_epoch_protocol_pubkey_bytes(self: &Validator): &Option> { + public fun next_epoch_protocol_pubkey_bytes(self: &ValidatorV1): &Option> { &self.metadata.next_epoch_protocol_pubkey_bytes } - public fun operation_cap_id(self: &Validator): &ID { + public fun operation_cap_id(self: &ValidatorV1): &ID { &self.operation_cap_id } - public fun next_epoch_gas_price(self: &Validator): u64 { + public fun next_epoch_gas_price(self: &ValidatorV1): u64 { self.next_epoch_gas_price } // TODO: this and `delegate_amount` and `total_stake` all seem to return the same value? // two of the functions can probably be removed. - public fun total_stake_amount(self: &Validator): u64 { + public fun total_stake_amount(self: &ValidatorV1): u64 { self.staking_pool.iota_balance() } - public fun stake_amount(self: &Validator): u64 { + public fun stake_amount(self: &ValidatorV1): u64 { self.staking_pool.iota_balance() } /// Return the total amount staked with this validator - public fun total_stake(self: &Validator): u64 { + public fun total_stake(self: &ValidatorV1): u64 { stake_amount(self) } /// Return the voting power of this validator. - public fun voting_power(self: &Validator): u64 { + public fun voting_power(self: &ValidatorV1): u64 { self.voting_power } /// Set the voting power of this validator, called only from validator_set. - public(package) fun set_voting_power(self: &mut Validator, new_voting_power: u64) { + public(package) fun set_voting_power(self: &mut ValidatorV1, new_voting_power: u64) { self.voting_power = new_voting_power; } - public fun pending_stake_amount(self: &Validator): u64 { + public fun pending_stake_amount(self: &ValidatorV1): u64 { self.staking_pool.pending_stake_amount() } - public fun pending_stake_withdraw_amount(self: &Validator): u64 { + public fun pending_stake_withdraw_amount(self: &ValidatorV1): u64 { self.staking_pool.pending_stake_withdraw_amount() } - public fun gas_price(self: &Validator): u64 { + public fun gas_price(self: &ValidatorV1): u64 { self.gas_price } - public fun commission_rate(self: &Validator): u64 { + public fun commission_rate(self: &ValidatorV1): u64 { self.commission_rate } - public fun pool_token_exchange_rate_at_epoch(self: &Validator, epoch: u64): PoolTokenExchangeRate { + public fun pool_token_exchange_rate_at_epoch(self: &ValidatorV1, epoch: u64): PoolTokenExchangeRate { self.staking_pool.pool_token_exchange_rate_at_epoch(epoch) } - public fun staking_pool_id(self: &Validator): ID { + public fun staking_pool_id(self: &ValidatorV1): ID { object::id(&self.staking_pool) } // MUSTFIX: We need to check this when updating metadata as well. - public fun is_duplicate(self: &Validator, other: &Validator): bool { + public fun is_duplicate(self: &ValidatorV1, other: &ValidatorV1): bool { self.metadata.iota_address == other.metadata.iota_address || self.metadata.name == other.metadata.name || self.metadata.net_address == other.metadata.net_address @@ -612,7 +612,7 @@ module iota_system::validator { /// Create a new `UnverifiedValidatorOperationCap`, transfer to the validator, /// and registers it, thus revoking the previous cap's permission. - public(package) fun new_unverified_validator_operation_cap_and_transfer(self: &mut Validator, ctx: &mut TxContext) { + public(package) fun new_unverified_validator_operation_cap_and_transfer(self: &mut ValidatorV1, ctx: &mut TxContext) { let address = ctx.sender(); assert!(address == self.metadata.iota_address, ENewCapNotCreatedByValidatorItself); let new_id = validator_cap::new_unverified_validator_operation_cap_and_transfer(address, ctx); @@ -620,7 +620,7 @@ module iota_system::validator { } /// Update name of the validator. - public(package) fun update_name(self: &mut Validator, name: vector) { + public(package) fun update_name(self: &mut ValidatorV1, name: vector) { assert!( name.length() <= MAX_VALIDATOR_METADATA_LENGTH, EValidatorMetadataExceedingLengthLimit @@ -629,7 +629,7 @@ module iota_system::validator { } /// Update description of the validator. - public(package) fun update_description(self: &mut Validator, description: vector) { + public(package) fun update_description(self: &mut ValidatorV1, description: vector) { assert!( description.length() <= MAX_VALIDATOR_METADATA_LENGTH, EValidatorMetadataExceedingLengthLimit @@ -638,7 +638,7 @@ module iota_system::validator { } /// Update image url of the validator. - public(package) fun update_image_url(self: &mut Validator, image_url: vector) { + public(package) fun update_image_url(self: &mut ValidatorV1, image_url: vector) { assert!( image_url.length() <= MAX_VALIDATOR_METADATA_LENGTH, EValidatorMetadataExceedingLengthLimit @@ -647,7 +647,7 @@ module iota_system::validator { } /// Update project url of the validator. - public(package) fun update_project_url(self: &mut Validator, project_url: vector) { + public(package) fun update_project_url(self: &mut ValidatorV1, project_url: vector) { assert!( project_url.length() <= MAX_VALIDATOR_METADATA_LENGTH, EValidatorMetadataExceedingLengthLimit @@ -656,7 +656,7 @@ module iota_system::validator { } /// Update network address of this validator, taking effects from next epoch - public(package) fun update_next_epoch_network_address(self: &mut Validator, net_address: vector) { + public(package) fun update_next_epoch_network_address(self: &mut ValidatorV1, net_address: vector) { assert!( net_address.length() <= MAX_VALIDATOR_METADATA_LENGTH, EValidatorMetadataExceedingLengthLimit @@ -667,7 +667,7 @@ module iota_system::validator { } /// Update network address of this candidate validator - public(package) fun update_candidate_network_address(self: &mut Validator, net_address: vector) { + public(package) fun update_candidate_network_address(self: &mut ValidatorV1, net_address: vector) { assert!(is_preactive(self), ENotValidatorCandidate); assert!( net_address.length() <= MAX_VALIDATOR_METADATA_LENGTH, @@ -679,7 +679,7 @@ module iota_system::validator { } /// Update p2p address of this validator, taking effects from next epoch - public(package) fun update_next_epoch_p2p_address(self: &mut Validator, p2p_address: vector) { + public(package) fun update_next_epoch_p2p_address(self: &mut ValidatorV1, p2p_address: vector) { assert!( p2p_address.length() <= MAX_VALIDATOR_METADATA_LENGTH, EValidatorMetadataExceedingLengthLimit @@ -690,7 +690,7 @@ module iota_system::validator { } /// Update p2p address of this candidate validator - public(package) fun update_candidate_p2p_address(self: &mut Validator, p2p_address: vector) { + public(package) fun update_candidate_p2p_address(self: &mut ValidatorV1, p2p_address: vector) { assert!(is_preactive(self), ENotValidatorCandidate); assert!( p2p_address.length() <= MAX_VALIDATOR_METADATA_LENGTH, @@ -702,7 +702,7 @@ module iota_system::validator { } /// Update primary address of this validator, taking effects from next epoch - public(package) fun update_next_epoch_primary_address(self: &mut Validator, primary_address: vector) { + public(package) fun update_next_epoch_primary_address(self: &mut ValidatorV1, primary_address: vector) { assert!( primary_address.length() <= MAX_VALIDATOR_METADATA_LENGTH, EValidatorMetadataExceedingLengthLimit @@ -713,7 +713,7 @@ module iota_system::validator { } /// Update primary address of this candidate validator - public(package) fun update_candidate_primary_address(self: &mut Validator, primary_address: vector) { + public(package) fun update_candidate_primary_address(self: &mut ValidatorV1, primary_address: vector) { assert!(is_preactive(self), ENotValidatorCandidate); assert!( primary_address.length() <= MAX_VALIDATOR_METADATA_LENGTH, @@ -725,14 +725,14 @@ module iota_system::validator { } /// Update authority public key of this validator, taking effects from next epoch - public(package) fun update_next_epoch_authority_pubkey(self: &mut Validator, authority_pubkey: vector, proof_of_possession: vector) { + public(package) fun update_next_epoch_authority_pubkey(self: &mut ValidatorV1, authority_pubkey: vector, proof_of_possession: vector) { self.metadata.next_epoch_authority_pubkey_bytes = option::some(authority_pubkey); self.metadata.next_epoch_proof_of_possession = option::some(proof_of_possession); validate_metadata(&self.metadata); } /// Update authority public key of this candidate validator - public(package) fun update_candidate_authority_pubkey(self: &mut Validator, authority_pubkey: vector, proof_of_possession: vector) { + public(package) fun update_candidate_authority_pubkey(self: &mut ValidatorV1, authority_pubkey: vector, proof_of_possession: vector) { assert!(is_preactive(self), ENotValidatorCandidate); self.metadata.authority_pubkey_bytes = authority_pubkey; self.metadata.proof_of_possession = proof_of_possession; @@ -740,26 +740,26 @@ module iota_system::validator { } /// Update network public key of this validator, taking effects from next epoch - public(package) fun update_next_epoch_network_pubkey(self: &mut Validator, network_pubkey: vector) { + public(package) fun update_next_epoch_network_pubkey(self: &mut ValidatorV1, network_pubkey: vector) { self.metadata.next_epoch_network_pubkey_bytes = option::some(network_pubkey); validate_metadata(&self.metadata); } /// Update network public key of this candidate validator - public(package) fun update_candidate_network_pubkey(self: &mut Validator, network_pubkey: vector) { + public(package) fun update_candidate_network_pubkey(self: &mut ValidatorV1, network_pubkey: vector) { assert!(is_preactive(self), ENotValidatorCandidate); self.metadata.network_pubkey_bytes = network_pubkey; validate_metadata(&self.metadata); } /// Update protocol public key of this validator, taking effects from next epoch - public(package) fun update_next_epoch_protocol_pubkey(self: &mut Validator, protocol_pubkey: vector) { + public(package) fun update_next_epoch_protocol_pubkey(self: &mut ValidatorV1, protocol_pubkey: vector) { self.metadata.next_epoch_protocol_pubkey_bytes = option::some(protocol_pubkey); validate_metadata(&self.metadata); } /// Update protocol public key of this candidate validator - public(package) fun update_candidate_protocol_pubkey(self: &mut Validator, protocol_pubkey: vector) { + public(package) fun update_candidate_protocol_pubkey(self: &mut ValidatorV1, protocol_pubkey: vector) { assert!(is_preactive(self), ENotValidatorCandidate); self.metadata.protocol_pubkey_bytes = protocol_pubkey; validate_metadata(&self.metadata); @@ -768,7 +768,7 @@ module iota_system::validator { /// Effectutate all staged next epoch metadata for this validator. /// NOTE: this function SHOULD ONLY be called by validator_set when /// advancing an epoch. - public(package) fun effectuate_staged_metadata(self: &mut Validator) { + public(package) fun effectuate_staged_metadata(self: &mut ValidatorV1) { if (next_epoch_network_address(self).is_some()) { self.metadata.net_address = self.metadata.next_epoch_net_address.extract(); self.metadata.next_epoch_net_address = option::none(); @@ -803,30 +803,30 @@ module iota_system::validator { } /// Aborts if validator metadata is valid - public fun validate_metadata(metadata: &ValidatorMetadata) { + public fun validate_metadata(metadata: &ValidatorMetadataV1) { validate_metadata_bcs(bcs::to_bytes(metadata)); } public native fun validate_metadata_bcs(metadata: vector); - public(package) fun get_staking_pool_ref(self: &Validator) : &StakingPool { + public(package) fun get_staking_pool_ref(self: &ValidatorV1) : &StakingPoolV1 { &self.staking_pool } - /// Create a new validator from the given `ValidatorMetadata`, called by both `new` and `new_for_testing`. + /// Create a new validator from the given `ValidatorMetadataV1`, called by both `new` and `new_for_testing`. fun new_from_metadata( - metadata: ValidatorMetadata, + metadata: ValidatorMetadataV1, gas_price: u64, commission_rate: u64, ctx: &mut TxContext - ): Validator { + ): ValidatorV1 { let iota_address = metadata.iota_address; let staking_pool = staking_pool::new(ctx); let operation_cap_id = validator_cap::new_unverified_validator_operation_cap_and_transfer(iota_address, ctx); - Validator { + ValidatorV1 { metadata, // Initialize the voting power to be 0. // At the epoch change where this validator is actually added to the @@ -867,7 +867,7 @@ module iota_system::validator { commission_rate: u64, is_active_at_genesis: bool, ctx: &mut TxContext - ): Validator { + ): ValidatorV1 { let mut validator = new_from_metadata( new_metadata( iota_address, diff --git a/crates/iota-framework/packages/iota-system/sources/validator_set.move b/crates/iota-framework/packages/iota-system/sources/validator_set.move index 649ea8b5cb0..a725dbc3a6a 100644 --- a/crates/iota-framework/packages/iota-system/sources/validator_set.move +++ b/crates/iota-framework/packages/iota-system/sources/validator_set.move @@ -6,7 +6,7 @@ module iota_system::validator_set { use iota::balance::Balance; use iota::iota::IOTA; - use iota_system::validator::{Validator, staking_pool_id, iota_address}; + use iota_system::validator::{ValidatorV1, staking_pool_id, iota_address}; use iota_system::validator_cap::{Self, UnverifiedValidatorOperationCap, ValidatorOperationCap}; use iota_system::staking_pool::{PoolTokenExchangeRate, StakedIota, pool_id}; use iota::priority_queue as pq; @@ -16,21 +16,21 @@ module iota_system::validator_set { use iota::event; use iota::table_vec::{Self, TableVec}; use iota_system::voting_power; - use iota_system::validator_wrapper::ValidatorWrapper; + use iota_system::validator_wrapper::Validator; use iota_system::validator_wrapper; use iota::bag::Bag; use iota::bag; - public struct ValidatorSet has store { + public struct ValidatorSetV1 has store { /// Total amount of stake from all active validators at the beginning of the epoch. total_stake: u64, /// The current list of active validators. - active_validators: vector, + active_validators: vector, /// List of new validator candidates added during the current epoch. /// They will be processed at the end of the epoch. - pending_active_validators: TableVec, + pending_active_validators: TableVec, /// Removal requests from the validators. Each element is an index /// pointing to `active_validators`. @@ -42,14 +42,14 @@ module iota_system::validator_set { /// Mapping from a staking pool ID to the inactive validator that has that pool as its staking pool. /// When a validator is deactivated the validator is removed from `active_validators` it /// is added to this table so that stakers can continue to withdraw their stake from it. - inactive_validators: Table, + inactive_validators: Table, - /// Table storing preactive/candidate validators, mapping their addresses to their `Validator ` structs. + /// Table storing preactive/candidate validators, mapping their addresses to their `ValidatorV1 ` structs. /// When an address calls `request_add_validator_candidate`, they get added to this table and become a preactive /// validator. /// When the candidate has met the min stake requirement, they can call `request_add_validator` to /// officially add them to the active validator set `active_validators` next epoch. - validator_candidates: Table, + validator_candidates: Table, /// Table storing the number of epochs during which a validator's stake has been below the low stake threshold. at_risk_validators: VecMap, @@ -61,20 +61,7 @@ module iota_system::validator_set { #[allow(unused_field)] /// Event containing staking and rewards related information of /// each validator, emitted during epoch advancement. - public struct ValidatorEpochInfoEvent has copy, drop { - epoch: u64, - validator_address: address, - reference_gas_survey_quote: u64, - stake: u64, - commission_rate: u64, - pool_staking_reward: u64, - pool_token_exchange_rate: PoolTokenExchangeRate, - tallying_rule_reporters: vector
, - tallying_rule_global_score: u64, - } - - /// V2 of ValidatorEpochInfoEvent containing more information about the validator. - public struct ValidatorEpochInfoEventV2 has copy, drop { + public struct ValidatorEpochInfoEventV1 has copy, drop { epoch: u64, validator_address: address, reference_gas_survey_quote: u64, @@ -134,7 +121,7 @@ module iota_system::validator_set { // ==== initialization at genesis ==== - public(package) fun new(init_active_validators: vector, ctx: &mut TxContext): ValidatorSet { + public(package) fun new(init_active_validators: vector, ctx: &mut TxContext): ValidatorSetV1 { let total_stake = calculate_total_stakes(&init_active_validators); let mut staking_pool_mappings = table::new(ctx); let num_validators = init_active_validators.length(); @@ -144,7 +131,7 @@ module iota_system::validator_set { staking_pool_mappings.add(staking_pool_id(validator), iota_address(validator)); i = i + 1; }; - let mut validators = ValidatorSet { + let mut validators = ValidatorSetV1 { total_stake, active_validators: init_active_validators, pending_active_validators: table_vec::empty(ctx), @@ -164,8 +151,8 @@ module iota_system::validator_set { /// Called by `iota_system` to add a new validator candidate. public(package) fun request_add_validator_candidate( - self: &mut ValidatorSet, - validator: Validator, + self: &mut ValidatorSetV1, + validator: ValidatorV1, ctx: &mut TxContext, ) { // The next assertions are not critical for the protocol, but they are here to catch problematic configs earlier. @@ -191,7 +178,7 @@ module iota_system::validator_set { } /// Called by `iota_system` to remove a validator candidate, and move them to `inactive_validators`. - public(package) fun request_remove_validator_candidate(self: &mut ValidatorSet, ctx: &mut TxContext) { + public(package) fun request_remove_validator_candidate(self: &mut ValidatorSetV1, ctx: &mut TxContext) { let validator_address = ctx.sender(); assert!( self.validator_candidates.contains(validator_address), @@ -218,7 +205,7 @@ module iota_system::validator_set { /// Called by `iota_system` to add a new validator to `pending_active_validators`, which will be /// processed at the end of epoch. - public(package) fun request_add_validator(self: &mut ValidatorSet, min_joining_stake_amount: u64, ctx: &TxContext) { + public(package) fun request_add_validator(self: &mut ValidatorSetV1, min_joining_stake_amount: u64, ctx: &TxContext) { let validator_address = ctx.sender(); assert!( self.validator_candidates.contains(validator_address), @@ -237,7 +224,7 @@ module iota_system::validator_set { self.pending_active_validators.push_back(validator); } - public(package) fun assert_no_pending_or_active_duplicates(self: &ValidatorSet, validator: &Validator) { + public(package) fun assert_no_pending_or_active_duplicates(self: &ValidatorSetV1, validator: &ValidatorV1) { // Validator here must be active or pending, and thus must be identified as duplicate exactly once. assert!( count_duplicates_vec(&self.active_validators, validator) + @@ -251,7 +238,7 @@ module iota_system::validator_set { /// will be processed at the end of epoch. /// Only an active validator can request to be removed. public(package) fun request_remove_validator( - self: &mut ValidatorSet, + self: &mut ValidatorSetV1, ctx: &TxContext, ) { let validator_address = ctx.sender(); @@ -273,7 +260,7 @@ module iota_system::validator_set { /// of the epoch. /// Aborts in case the staking amount is smaller than MIN_STAKING_THRESHOLD public(package) fun request_add_stake( - self: &mut ValidatorSet, + self: &mut ValidatorSetV1, validator_address: address, stake: Balance, ctx: &mut TxContext, @@ -291,7 +278,7 @@ module iota_system::validator_set { /// 2. If the `staked_iota` was staked with a validator that is no longer active, /// the stake and any rewards corresponding to it will be immediately processed. public(package) fun request_withdraw_stake( - self: &mut ValidatorSet, + self: &mut ValidatorSetV1, staked_iota: StakedIota, ctx: &TxContext, ) : Balance { @@ -311,7 +298,7 @@ module iota_system::validator_set { // ==== validator config setting functions ==== public(package) fun request_set_commission_rate( - self: &mut ValidatorSet, + self: &mut ValidatorSetV1, new_commission_rate: u64, ctx: &TxContext, ) { @@ -331,7 +318,7 @@ module iota_system::validator_set { /// 4. Process pending validator application and withdraws. /// 5. At the end, we calculate the total stake for the new epoch. public(package) fun advance_epoch( - self: &mut ValidatorSet, + self: &mut ValidatorSetV1, total_validator_rewards: &mut Balance, validator_report_records: &mut VecMap>, reward_slashing_rate: u64, @@ -420,7 +407,7 @@ module iota_system::validator_set { } fun update_and_process_low_stake_departures( - self: &mut ValidatorSet, + self: &mut ValidatorSetV1, low_stake_threshold: u64, very_low_stake_threshold: u64, low_stake_grace_period: u64, @@ -466,7 +453,7 @@ module iota_system::validator_set { /// Effectutate pending next epoch metadata if they are staged. fun effectuate_staged_metadata( - self: &mut ValidatorSet, + self: &mut ValidatorSetV1, ) { let num_validators = self.active_validators.length(); let mut i = 0; @@ -481,7 +468,7 @@ module iota_system::validator_set { /// Derive the reference gas price based on the gas price quote submitted by each validator. /// The returned gas price should be greater than or equal to 2/3 of the validators submitted /// gas price, weighted by stake. - public fun derive_reference_gas_price(self: &ValidatorSet): u64 { + public fun derive_reference_gas_price(self: &ValidatorSetV1): u64 { let vs = &self.active_validators; let num_validators = vs.length(); let mut entries = vector[]; @@ -508,36 +495,36 @@ module iota_system::validator_set { // ==== getter functions ==== - public fun total_stake(self: &ValidatorSet): u64 { + public fun total_stake(self: &ValidatorSetV1): u64 { self.total_stake } - public fun validator_total_stake_amount(self: &ValidatorSet, validator_address: address): u64 { + public fun validator_total_stake_amount(self: &ValidatorSetV1, validator_address: address): u64 { let validator = get_validator_ref(&self.active_validators, validator_address); validator.total_stake_amount() } - public fun validator_stake_amount(self: &ValidatorSet, validator_address: address): u64 { + public fun validator_stake_amount(self: &ValidatorSetV1, validator_address: address): u64 { let validator = get_validator_ref(&self.active_validators, validator_address); validator.stake_amount() } - public fun validator_voting_power(self: &ValidatorSet, validator_address: address): u64 { + public fun validator_voting_power(self: &ValidatorSetV1, validator_address: address): u64 { let validator = get_validator_ref(&self.active_validators, validator_address); validator.voting_power() } - public fun validator_staking_pool_id(self: &ValidatorSet, validator_address: address): ID { + public fun validator_staking_pool_id(self: &ValidatorSetV1, validator_address: address): ID { let validator = get_validator_ref(&self.active_validators, validator_address); validator.staking_pool_id() } - public fun staking_pool_mappings(self: &ValidatorSet): &Table { + public fun staking_pool_mappings(self: &ValidatorSetV1): &Table { &self.staking_pool_mappings } public(package) fun pool_exchange_rates( - self: &mut ValidatorSet, pool_id: &ID + self: &mut ValidatorSetV1, pool_id: &ID ) : &Table { let validator = // If the pool id is recorded in the mapping, then it must be either candidate or active. @@ -552,13 +539,13 @@ module iota_system::validator_set { } /// Get the total number of validators in the next epoch. - public(package) fun next_epoch_validator_count(self: &ValidatorSet): u64 { + public(package) fun next_epoch_validator_count(self: &ValidatorSetV1): u64 { self.active_validators.length() - self.pending_removals.length() + self.pending_active_validators.length() } /// Returns true iff the address exists in active validators. public(package) fun is_active_validator_by_iota_address( - self: &ValidatorSet, + self: &ValidatorSetV1, validator_address: address, ): bool { find_validator(&self.active_validators, validator_address).is_some() @@ -569,15 +556,15 @@ module iota_system::validator_set { /// Checks whether `new_validator` is duplicate with any currently active validators. /// It differs from `is_active_validator_by_iota_address` in that the former checks /// only the iota address but this function looks at more metadata. - fun is_duplicate_with_active_validator(self: &ValidatorSet, new_validator: &Validator): bool { + fun is_duplicate_with_active_validator(self: &ValidatorSetV1, new_validator: &ValidatorV1): bool { is_duplicate_validator(&self.active_validators, new_validator) } - public(package) fun is_duplicate_validator(validators: &vector, new_validator: &Validator): bool { + public(package) fun is_duplicate_validator(validators: &vector, new_validator: &ValidatorV1): bool { count_duplicates_vec(validators, new_validator) > 0 } - fun count_duplicates_vec(validators: &vector, validator: &Validator): u64 { + fun count_duplicates_vec(validators: &vector, validator: &ValidatorV1): u64 { let len = validators.length(); let mut i = 0; let mut result = 0; @@ -592,11 +579,11 @@ module iota_system::validator_set { } /// Checks whether `new_validator` is duplicate with any currently pending validators. - fun is_duplicate_with_pending_validator(self: &ValidatorSet, new_validator: &Validator): bool { + fun is_duplicate_with_pending_validator(self: &ValidatorSetV1, new_validator: &ValidatorV1): bool { count_duplicates_tablevec(&self.pending_active_validators, new_validator) > 0 } - fun count_duplicates_tablevec(validators: &TableVec, validator: &Validator): u64 { + fun count_duplicates_tablevec(validators: &TableVec, validator: &ValidatorV1): u64 { let len = validators.length(); let mut i = 0; let mut result = 0; @@ -611,7 +598,7 @@ module iota_system::validator_set { } /// Get mutable reference to either a candidate or an active validator by address. - fun get_candidate_or_active_validator_mut(self: &mut ValidatorSet, validator_address: address): &mut Validator { + fun get_candidate_or_active_validator_mut(self: &mut ValidatorSetV1, validator_address: address): &mut ValidatorV1 { if (self.validator_candidates.contains(validator_address)) { let wrapper = &mut self.validator_candidates[validator_address]; return wrapper.load_validator_maybe_upgrade() @@ -622,7 +609,7 @@ module iota_system::validator_set { /// Find validator by `validator_address`, in `validators`. /// Returns (true, index) if the validator is found, and the index is its index in the list. /// If not found, returns (false, 0). - fun find_validator(validators: &vector, validator_address: address): Option { + fun find_validator(validators: &vector, validator_address: address): Option { let length = validators.length(); let mut i = 0; while (i < length) { @@ -638,7 +625,7 @@ module iota_system::validator_set { /// Find validator by `validator_address`, in `validators`. /// Returns (true, index) if the validator is found, and the index is its index in the list. /// If not found, returns (false, 0). - fun find_validator_from_table_vec(validators: &TableVec, validator_address: address): Option { + fun find_validator_from_table_vec(validators: &TableVec, validator_address: address): Option { let length = validators.length(); let mut i = 0; while (i < length) { @@ -654,7 +641,7 @@ module iota_system::validator_set { /// Given a vector of validator addresses, return their indices in the validator set. /// Aborts if any address isn't in the given validator set. - fun get_validator_indices(validators: &vector, validator_addresses: &vector
): vector { + fun get_validator_indices(validators: &vector, validator_addresses: &vector
): vector { let length = validator_addresses.length(); let mut i = 0; let mut res = vector[]; @@ -669,9 +656,9 @@ module iota_system::validator_set { } public(package) fun get_validator_mut( - validators: &mut vector, + validators: &mut vector, validator_address: address, - ): &mut Validator { + ): &mut ValidatorV1 { let mut validator_index_opt = find_validator(validators, validator_address); assert!(validator_index_opt.is_some(), ENotAValidator); let validator_index = validator_index_opt.extract(); @@ -681,12 +668,12 @@ module iota_system::validator_set { /// Get mutable reference to an active or (if active does not exist) pending or (if pending and /// active do not exist) or candidate validator by address. /// Note: this function should be called carefully, only after verifying the transaction - /// sender has the ability to modify the `Validator`. + /// sender has the ability to modify the `ValidatorV1`. fun get_active_or_pending_or_candidate_validator_mut( - self: &mut ValidatorSet, + self: &mut ValidatorSetV1, validator_address: address, include_candidate: bool, - ): &mut Validator { + ): &mut ValidatorV1 { let mut validator_index_opt = find_validator(&self.active_validators, validator_address); if (validator_index_opt.is_some()) { let validator_index = validator_index_opt.extract(); @@ -704,33 +691,33 @@ module iota_system::validator_set { } public(package) fun get_validator_mut_with_verified_cap( - self: &mut ValidatorSet, + self: &mut ValidatorSetV1, verified_cap: &ValidatorOperationCap, include_candidate: bool, - ): &mut Validator { + ): &mut ValidatorV1 { get_active_or_pending_or_candidate_validator_mut(self, *verified_cap.verified_operation_cap_address(), include_candidate) } public(package) fun get_validator_mut_with_ctx( - self: &mut ValidatorSet, + self: &mut ValidatorSetV1, ctx: &TxContext, - ): &mut Validator { + ): &mut ValidatorV1 { let validator_address = ctx.sender(); get_active_or_pending_or_candidate_validator_mut(self, validator_address, false) } public(package) fun get_validator_mut_with_ctx_including_candidates( - self: &mut ValidatorSet, + self: &mut ValidatorSetV1, ctx: &TxContext, - ): &mut Validator { + ): &mut ValidatorV1 { let validator_address = ctx.sender(); get_active_or_pending_or_candidate_validator_mut(self, validator_address, true) } fun get_validator_ref( - validators: &vector, + validators: &vector, validator_address: address, - ): &Validator { + ): &ValidatorV1 { let mut validator_index_opt = find_validator(validators, validator_address); assert!(validator_index_opt.is_some(), ENotAValidator); let validator_index = validator_index_opt.extract(); @@ -738,10 +725,10 @@ module iota_system::validator_set { } public(package) fun get_active_or_pending_or_candidate_validator_ref( - self: &mut ValidatorSet, + self: &mut ValidatorSetV1, validator_address: address, which_validator: u8, - ): &Validator { + ): &ValidatorV1 { let mut validator_index_opt = find_validator(&self.active_validators, validator_address); if (validator_index_opt.is_some() || which_validator == ACTIVE_VALIDATOR_ONLY) { let validator_index = validator_index_opt.extract(); @@ -756,9 +743,9 @@ module iota_system::validator_set { } public fun get_active_validator_ref( - self: &ValidatorSet, + self: &ValidatorSetV1, validator_address: address, - ): &Validator { + ): &ValidatorV1 { let mut validator_index_opt = find_validator(&self.active_validators, validator_address); assert!(validator_index_opt.is_some(), ENotAValidator); let validator_index = validator_index_opt.extract(); @@ -766,9 +753,9 @@ module iota_system::validator_set { } public fun get_pending_validator_ref( - self: &ValidatorSet, + self: &ValidatorSetV1, validator_address: address, - ): &Validator { + ): &ValidatorV1 { let mut validator_index_opt = find_validator_from_table_vec(&self.pending_active_validators, validator_address); assert!(validator_index_opt.is_some(), ENotAPendingValidator); let validator_index = validator_index_opt.extract(); @@ -777,9 +764,9 @@ module iota_system::validator_set { #[test_only] public fun get_candidate_validator_ref( - self: &ValidatorSet, + self: &ValidatorSetV1, validator_address: address, - ): &Validator { + ): &ValidatorV1 { self.validator_candidates[validator_address].get_inner_validator_ref() } @@ -787,7 +774,7 @@ module iota_system::validator_set { /// If `active_validator_only` is true, only verify the Cap for an active validator. /// Otherwise, verify the Cap for au either active or pending validator. public(package) fun verify_cap( - self: &mut ValidatorSet, + self: &mut ValidatorSetV1, cap: &UnverifiedValidatorOperationCap, which_validator: u8, ): ValidatorOperationCap { @@ -804,7 +791,7 @@ module iota_system::validator_set { /// Process the pending withdraw requests. For each pending request, the validator /// is removed from `validators` and its staking pool is put into the `inactive_validators` table. fun process_pending_removals( - self: &mut ValidatorSet, + self: &mut ValidatorSetV1, validator_report_records: &mut VecMap>, ctx: &mut TxContext, ) { @@ -817,8 +804,8 @@ module iota_system::validator_set { } fun process_validator_departure( - self: &mut ValidatorSet, - mut validator: Validator, + self: &mut ValidatorSetV1, + mut validator: ValidatorV1, validator_report_records: &mut VecMap>, is_voluntary: bool, ctx: &mut TxContext, @@ -882,7 +869,7 @@ module iota_system::validator_set { /// Process the pending new validators. They are activated and inserted into `validators`. fun process_pending_validators( - self: &mut ValidatorSet, new_epoch: u64, + self: &mut ValidatorSetV1, new_epoch: u64, ) { while (!self.pending_active_validators.is_empty()) { let mut validator = self.pending_active_validators.pop_back(); @@ -919,7 +906,7 @@ module iota_system::validator_set { /// Process all active validators' pending stake deposits and withdraws. fun process_pending_stakes_and_withdraws( - validators: &mut vector, ctx: &TxContext + validators: &mut vector, ctx: &TxContext ) { let length = validators.length(); let mut i = 0; @@ -931,7 +918,7 @@ module iota_system::validator_set { } /// Calculate the total active validator stake. - fun calculate_total_stakes(validators: &vector): u64 { + fun calculate_total_stakes(validators: &vector): u64 { let mut stake = 0; let length = validators.length(); let mut i = 0; @@ -944,7 +931,7 @@ module iota_system::validator_set { } /// Process the pending stake changes for each validator. - fun adjust_stake_and_gas_price(validators: &mut vector) { + fun adjust_stake_and_gas_price(validators: &mut vector) { let length = validators.length(); let mut i = 0; while (i < length) { @@ -986,7 +973,7 @@ module iota_system::validator_set { /// Process the validator report records of the epoch and return the addresses of the /// non-performant validators according to the input threshold. fun compute_slashed_validators( - self: &ValidatorSet, + self: &ValidatorSetV1, mut validator_report_records: VecMap>, ): vector
{ let mut slashed_validators = vector[]; @@ -1011,7 +998,7 @@ module iota_system::validator_set { /// account the tallying rule results. /// Returns the unadjusted amounts of staking reward for each validator. fun compute_unadjusted_reward_distribution( - validators: &vector, + validators: &vector, total_voting_power: u64, total_staking_reward: u64, ): vector { @@ -1035,7 +1022,7 @@ module iota_system::validator_set { /// Returns the staking rewards each validator gets. /// The staking rewards are shared with the stakers. fun compute_adjusted_reward_distribution( - validators: &vector, + validators: &vector, total_voting_power: u64, total_slashed_validator_voting_power: u64, unadjusted_staking_reward_amounts: vector, @@ -1078,7 +1065,7 @@ module iota_system::validator_set { } fun distribute_reward( - validators: &mut vector, + validators: &mut vector, adjusted_staking_reward_amounts: &vector, staking_rewards: &mut Balance, ctx: &mut TxContext @@ -1116,7 +1103,7 @@ module iota_system::validator_set { /// including stakes, rewards, performance, etc. fun emit_validator_epoch_events( new_epoch: u64, - vs: &vector, + vs: &vector, pool_staking_reward_amounts: &vector, report_records: &VecMap>, slashed_validators: &vector
, @@ -1136,7 +1123,7 @@ module iota_system::validator_set { if (slashed_validators.contains(&validator_address)) 0 else 1; event::emit( - ValidatorEpochInfoEventV2 { + ValidatorEpochInfoEventV1 { epoch: new_epoch, validator_address, reference_gas_survey_quote: v.gas_price(), @@ -1154,7 +1141,7 @@ module iota_system::validator_set { } /// Sum up the total stake of a given list of validator addresses. - public fun sum_voting_power_by_addresses(vs: &vector, addresses: &vector
): u64 { + public fun sum_voting_power_by_addresses(vs: &vector, addresses: &vector
): u64 { let mut sum = 0; let mut i = 0; let length = addresses.length(); @@ -1167,21 +1154,21 @@ module iota_system::validator_set { } /// Return the active validators in `self` - public fun active_validators(self: &ValidatorSet): &vector { + public fun active_validators(self: &ValidatorSetV1): &vector { &self.active_validators } /// Returns true if the `addr` is a validator candidate. - public fun is_validator_candidate(self: &ValidatorSet, addr: address): bool { + public fun is_validator_candidate(self: &ValidatorSetV1, addr: address): bool { self.validator_candidates.contains(addr) } /// Returns true if the staking pool identified by `staking_pool_id` is of an inactive validator. - public fun is_inactive_validator(self: &ValidatorSet, staking_pool_id: ID): bool { + public fun is_inactive_validator(self: &ValidatorSetV1, staking_pool_id: ID): bool { self.inactive_validators.contains(staking_pool_id) } - public(package) fun active_validator_addresses(self: &ValidatorSet): vector
{ + public(package) fun active_validator_addresses(self: &ValidatorSetV1): vector
{ let vs = &self.active_validators; let mut res = vector[]; let mut i = 0; diff --git a/crates/iota-framework/packages/iota-system/sources/validator_wrapper.move b/crates/iota-framework/packages/iota-system/sources/validator_wrapper.move index 81e0d53100a..f4932d4c6fa 100644 --- a/crates/iota-framework/packages/iota-system/sources/validator_wrapper.move +++ b/crates/iota-framework/packages/iota-system/sources/validator_wrapper.move @@ -4,49 +4,49 @@ module iota_system::validator_wrapper { use iota::versioned::Versioned; - use iota_system::validator::Validator; + use iota_system::validator::ValidatorV1; use iota::versioned; const EInvalidVersion: u64 = 0; - public struct ValidatorWrapper has store { + public struct Validator has store { inner: Versioned } - // Validator corresponds to version 1. - public(package) fun create_v1(validator: Validator, ctx: &mut TxContext): ValidatorWrapper { - ValidatorWrapper { + // ValidatorV1 corresponds to version 1. + public(package) fun create_v1(validator: ValidatorV1, ctx: &mut TxContext): Validator { + Validator { inner: versioned::create(1, validator, ctx) } } /// This function should always return the latest supported version. /// If the inner version is old, we upgrade it lazily in-place. - public(package) fun load_validator_maybe_upgrade(self: &mut ValidatorWrapper): &mut Validator { + public(package) fun load_validator_maybe_upgrade(self: &mut Validator): &mut ValidatorV1 { upgrade_to_latest(self); versioned::load_value_mut(&mut self.inner) } /// Destroy the wrapper and retrieve the inner validator object. - public(package) fun destroy(self: ValidatorWrapper): Validator { + public(package) fun destroy(self: Validator): ValidatorV1 { upgrade_to_latest(&self); - let ValidatorWrapper { inner } = self; + let Validator { inner } = self; versioned::destroy(inner) } #[test_only] /// Load the inner validator with assumed type. This should be used for testing only. - public(package) fun get_inner_validator_ref(self: &ValidatorWrapper): &Validator { + public(package) fun get_inner_validator_ref(self: &Validator): &ValidatorV1 { versioned::load_value(&self.inner) } - fun upgrade_to_latest(self: &ValidatorWrapper) { + fun upgrade_to_latest(self: &Validator) { let version = version(self); // TODO: When new versions are added, we need to explicitly upgrade here. assert!(version == 1, EInvalidVersion); } - fun version(self: &ValidatorWrapper): u64 { + fun version(self: &Validator): u64 { versioned::version(&self.inner) } } diff --git a/crates/iota-framework/packages/iota-system/sources/voting_power.move b/crates/iota-framework/packages/iota-system/sources/voting_power.move index d5a0cc68b8b..2c839fe6a84 100644 --- a/crates/iota-framework/packages/iota-system/sources/voting_power.move +++ b/crates/iota-framework/packages/iota-system/sources/voting_power.move @@ -3,16 +3,9 @@ // SPDX-License-Identifier: Apache-2.0 module iota_system::voting_power { - use iota_system::validator::Validator; + use iota_system::validator::ValidatorV1; - #[allow(unused_field)] - /// Deprecated. Use VotingPowerInfoV2 instead. - public struct VotingPowerInfo has drop { - validator_index: u64, - voting_power: u64, - } - - public struct VotingPowerInfoV2 has drop { + public struct VotingPowerInfoV1 has drop { validator_index: u64, voting_power: u64, stake: u64, @@ -41,7 +34,7 @@ module iota_system::voting_power { /// Set the voting power of all validators. /// Each validator's voting power is initialized using their stake. We then attempt to cap their voting power /// at `MAX_VOTING_POWER`. If `MAX_VOTING_POWER` is not a feasible cap, we pick the lowest possible cap. - public(package) fun set_voting_power(validators: &mut vector) { + public(package) fun set_voting_power(validators: &mut vector) { // If threshold_pct is too small, it's possible that even when all validators reach the threshold we still don't // have 100%. So we bound the threshold_pct to be always enough to find a solution. let threshold = TOTAL_VOTING_POWER.min( @@ -58,9 +51,9 @@ module iota_system::voting_power { /// descending order using voting power. /// Anything beyond the threshold is added to the remaining_power, which is also returned. fun init_voting_power_info( - validators: &vector, + validators: &vector, threshold: u64, - ): (vector, u64) { + ): (vector, u64) { let total_stake = total_stake(validators); let mut i = 0; let len = validators.length(); @@ -71,7 +64,7 @@ module iota_system::voting_power { let stake = validator.total_stake(); let adjusted_stake = stake as u128 * (TOTAL_VOTING_POWER as u128) / (total_stake as u128); let voting_power = (adjusted_stake as u64).min(threshold); - let info = VotingPowerInfoV2 { + let info = VotingPowerInfoV1 { validator_index: i, voting_power, stake, @@ -84,7 +77,7 @@ module iota_system::voting_power { } /// Sum up the total stake of all validators. - fun total_stake(validators: &vector): u64 { + fun total_stake(validators: &vector): u64 { let mut i = 0; let len = validators.length(); let mut total_stake =0 ; @@ -97,7 +90,7 @@ module iota_system::voting_power { /// Insert `new_info` to `info_list` as part of insertion sort, such that `info_list` is always sorted /// using stake, in descending order. - fun insert(info_list: &mut vector, new_info: VotingPowerInfoV2) { + fun insert(info_list: &mut vector, new_info: VotingPowerInfoV1) { let mut i = 0; let len = info_list.length(); while (i < len && info_list[i].stake > new_info.stake) { @@ -107,7 +100,7 @@ module iota_system::voting_power { } /// Distribute remaining_power to validators that are not capped at threshold. - fun adjust_voting_power(info_list: &mut vector, threshold: u64, mut remaining_power: u64) { + fun adjust_voting_power(info_list: &mut vector, threshold: u64, mut remaining_power: u64) { let mut i = 0; let len = info_list.length(); while (i < len && remaining_power > 0) { @@ -127,9 +120,9 @@ module iota_system::voting_power { } /// Update validators with the decided voting power. - fun update_voting_power(validators: &mut vector, mut info_list: vector) { + fun update_voting_power(validators: &mut vector, mut info_list: vector) { while (!info_list.is_empty()) { - let VotingPowerInfoV2 { + let VotingPowerInfoV1 { validator_index, voting_power, stake: _, @@ -141,7 +134,7 @@ module iota_system::voting_power { } /// Check a few invariants that must hold after setting the voting power. - fun check_invariants(v: &vector) { + fun check_invariants(v: &vector) { // First check that the total voting power must be TOTAL_VOTING_POWER. let mut i = 0; let len = v.length(); diff --git a/crates/iota-framework/packages/iota-system/tests/governance_test_utils.move b/crates/iota-framework/packages/iota-system/tests/governance_test_utils.move index ecbcd3e902c..97d3af016ca 100644 --- a/crates/iota-framework/packages/iota-system/tests/governance_test_utils.move +++ b/crates/iota-framework/packages/iota-system/tests/governance_test_utils.move @@ -8,9 +8,9 @@ module iota_system::governance_test_utils { use iota::balance; use iota::iota::{Self, IOTA}; use iota::coin::{Self, Coin}; - use iota_system::staking_pool::{StakedIota, StakingPool}; + use iota_system::staking_pool::{StakedIota, StakingPoolV1}; use iota::test_utils::assert_eq; - use iota_system::validator::{Self, Validator}; + use iota_system::validator::{Self, ValidatorV1}; use iota_system::iota_system::{Self, IotaSystemState}; use iota_system::iota_system_state_inner; use iota::test_scenario::{Self, Scenario}; @@ -22,7 +22,7 @@ module iota_system::governance_test_utils { public fun create_validator_for_testing( addr: address, init_stake_amount_in_iota: u64, ctx: &mut TxContext - ): Validator { + ): ValidatorV1 { let validator = validator::new_for_testing( addr, x"AA", @@ -46,7 +46,7 @@ module iota_system::governance_test_utils { } /// Create a validator set with the given stake amounts - public fun create_validators_with_stakes(stakes: vector, ctx: &mut TxContext): vector { + public fun create_validators_with_stakes(stakes: vector, ctx: &mut TxContext): vector { let mut i = 0; let mut validators = vector[]; while (i < stakes.length()) { @@ -58,7 +58,7 @@ module iota_system::governance_test_utils { } public fun create_iota_system_state_for_testing( - validators: vector, iota_supply_amount: u64, storage_fund_amount: u64, ctx: &mut TxContext + validators: vector, iota_supply_amount: u64, storage_fund_amount: u64, ctx: &mut TxContext ) { let system_parameters = iota_system_state_inner::create_system_parameters( 42, // epoch_duration_ms, doesn't matter what number we put here @@ -325,7 +325,7 @@ module iota_system::governance_test_utils { amount } - public fun stake_plus_current_rewards(addr: address, staking_pool: &StakingPool, scenario: &mut Scenario): u64 { + public fun stake_plus_current_rewards(addr: address, staking_pool: &StakingPoolV1, scenario: &mut Scenario): u64 { let mut sum = 0; scenario.next_tx(addr); let mut stake_ids = scenario.ids_for_sender(); diff --git a/crates/iota-framework/packages/iota-system/tests/iota_system_tests.move b/crates/iota-framework/packages/iota-system/tests/iota_system_tests.move index e920a90b036..18d51aaff4b 100644 --- a/crates/iota-framework/packages/iota-system/tests/iota_system_tests.move +++ b/crates/iota-framework/packages/iota-system/tests/iota_system_tests.move @@ -13,7 +13,7 @@ module iota_system::iota_system_tests { use iota_system::governance_test_utils::{add_validator_full_flow, advance_epoch, remove_validator, set_up_iota_system_state, create_iota_system_state_for_testing, stake_with, unstake}; use iota_system::iota_system::IotaSystemState; use iota_system::iota_system_state_inner; - use iota_system::validator::{Self, Validator}; + use iota_system::validator::{Self, ValidatorV1}; use iota_system::validator_set; use iota_system::validator_cap::UnverifiedValidatorOperationCap; use iota::balance; @@ -382,7 +382,7 @@ module iota_system::iota_system_tests { fun verify_candidate( - validator: &Validator, + validator: &ValidatorV1, name: vector, authority_pub_key: vector, pop: vector, @@ -439,7 +439,7 @@ module iota_system::iota_system_tests { } fun verify_metadata( - validator: &Validator, + validator: &ValidatorV1, name: vector, authority_pub_key: vector, pop: vector, @@ -490,7 +490,7 @@ module iota_system::iota_system_tests { } fun verify_current_epoch_metadata( - validator: &Validator, + validator: &ValidatorV1, name: vector, authority_pub_key: vector, pop: vector, @@ -516,7 +516,7 @@ module iota_system::iota_system_tests { fun verify_metadata_after_advancing_epoch( - validator: &Validator, + validator: &ValidatorV1, name: vector, authority_pub_key: vector, pop: vector, diff --git a/crates/iota-framework/packages/iota-system/tests/timelocked_delegation_tests.move b/crates/iota-framework/packages/iota-system/tests/timelocked_delegation_tests.move index 2b2ba3689d0..e7d1ba96f28 100644 --- a/crates/iota-framework/packages/iota-system/tests/timelocked_delegation_tests.move +++ b/crates/iota-framework/packages/iota-system/tests/timelocked_delegation_tests.move @@ -15,7 +15,7 @@ module iota_system::timelocked_stake_tests { use iota_system::iota_system::IotaSystemState; use iota_system::staking_pool::{Self, PoolTokenExchangeRate}; - use iota_system::validator_set::{Self, ValidatorSet}; + use iota_system::validator_set::{Self, ValidatorSetV1}; use iota_system::governance_test_utils::{ add_validator, add_validator_candidate, @@ -1115,7 +1115,7 @@ module iota_system::timelocked_stake_tests { scenario.has_most_recent_for_sender>() } - fun is_active_validator_by_iota_address(set: &ValidatorSet, validator_address: address): bool { + fun is_active_validator_by_iota_address(set: &ValidatorSetV1, validator_address: address): bool { let validators = set.active_validators(); let length = validators.length(); let mut i = 0; diff --git a/crates/iota-framework/packages/iota-system/tests/validator_set_tests.move b/crates/iota-framework/packages/iota-system/tests/validator_set_tests.move index 4e002a7cc2d..eb9c1981e41 100644 --- a/crates/iota-framework/packages/iota-system/tests/validator_set_tests.move +++ b/crates/iota-framework/packages/iota-system/tests/validator_set_tests.move @@ -7,8 +7,8 @@ module iota_system::validator_set_tests { use iota::balance; use iota::coin; use iota_system::staking_pool::StakedIota; - use iota_system::validator::{Self, Validator, staking_pool_id}; - use iota_system::validator_set::{Self, ValidatorSet, active_validator_addresses}; + use iota_system::validator::{Self, ValidatorV1, staking_pool_id}; + use iota_system::validator_set::{Self, ValidatorSetV1, active_validator_addresses}; use iota::test_scenario::{Self, Scenario}; use iota::test_utils::{Self, assert_eq}; use iota::vec_map; @@ -399,7 +399,7 @@ module iota_system::validator_set_tests { scenario_val.end(); } - fun create_validator(addr: address, hint: u8, gas_price: u64, is_initial_validator: bool, ctx: &mut TxContext): Validator { + fun create_validator(addr: address, hint: u8, gas_price: u64, is_initial_validator: bool, ctx: &mut TxContext): ValidatorV1 { let stake_value = hint as u64 * 100 * NANOS_PER_IOTA; let name = hint_to_ascii(hint); let validator = validator::new_for_testing( @@ -429,7 +429,7 @@ module iota_system::validator_set_tests { ascii_bytes.to_ascii_string().into_bytes() } - fun advance_epoch_with_dummy_rewards(validator_set: &mut ValidatorSet, scenario: &mut Scenario) { + fun advance_epoch_with_dummy_rewards(validator_set: &mut ValidatorSetV1, scenario: &mut Scenario) { scenario.next_epoch(@0x0); let mut dummy_computation_reward = balance::zero(); @@ -447,7 +447,7 @@ module iota_system::validator_set_tests { } fun advance_epoch_with_low_stake_params( - validator_set: &mut ValidatorSet, + validator_set: &mut ValidatorSetV1, low_stake_threshold: u64, very_low_stake_threshold: u64, low_stake_grace_period: u64, @@ -468,7 +468,7 @@ module iota_system::validator_set_tests { dummy_computation_reward.destroy_zero(); } - fun add_and_activate_validator(validator_set: &mut ValidatorSet, validator: Validator, scenario: &mut Scenario) { + fun add_and_activate_validator(validator_set: &mut ValidatorSetV1, validator: ValidatorV1, scenario: &mut Scenario) { scenario.next_tx(validator.iota_address()); let ctx = scenario.ctx(); validator_set.request_add_validator_candidate(validator, ctx); diff --git a/crates/iota-framework/packages/iota-system/tests/validator_tests.move b/crates/iota-framework/packages/iota-system/tests/validator_tests.move index b69590d5aec..99e992fd21c 100644 --- a/crates/iota-framework/packages/iota-system/tests/validator_tests.move +++ b/crates/iota-framework/packages/iota-system/tests/validator_tests.move @@ -12,7 +12,7 @@ module iota_system::validator_tests { use iota::test_utils; use iota::url; use iota_system::staking_pool::StakedIota; - use iota_system::validator::{Self, Validator}; + use iota_system::validator::{Self, ValidatorV1}; const VALID_NET_PUBKEY: vector = vector[171, 2, 39, 3, 139, 105, 166, 171, 153, 151, 102, 197, 151, 186, 140, 116, 114, 90, 213, 225, 20, 167, 60, 69, 203, 12, 180, 198, 9, 217, 117, 38]; @@ -31,7 +31,7 @@ module iota_system::validator_tests { const TOO_LONG_257_BYTES: vector = b"aaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaaa"; #[test_only] - fun get_test_validator(ctx: &mut TxContext): Validator { + fun get_test_validator(ctx: &mut TxContext): ValidatorV1 { let init_stake = coin::mint_for_testing(10_000_000_000, ctx).into_balance(); let mut validator = validator::new( VALID_ADDRESS, @@ -582,7 +582,7 @@ module iota_system::validator_tests { tear_down(validator, scenario); } - fun set_up(): (address, test_scenario::Scenario, validator::Validator) { + fun set_up(): (address, test_scenario::Scenario, validator::ValidatorV1) { let sender = VALID_ADDRESS; let mut scenario_val = test_scenario::begin(sender); let ctx = scenario_val.ctx(); @@ -590,7 +590,7 @@ module iota_system::validator_tests { (sender, scenario_val, validator) } - fun tear_down(validator: validator::Validator, scenario: test_scenario::Scenario) { + fun tear_down(validator: validator::ValidatorV1, scenario: test_scenario::Scenario) { test_utils::destroy(validator); scenario.end(); } diff --git a/crates/iota-framework/packages/iota-system/tests/voting_power_tests.move b/crates/iota-framework/packages/iota-system/tests/voting_power_tests.move index 799ca5dc71c..f9aa8ac8965 100644 --- a/crates/iota-framework/packages/iota-system/tests/voting_power_tests.move +++ b/crates/iota-framework/packages/iota-system/tests/voting_power_tests.move @@ -8,7 +8,7 @@ module iota_system::voting_power_tests { use iota_system::voting_power; use iota::test_scenario; use iota::test_utils; - use iota_system::validator::{Self, Validator}; + use iota_system::validator::{Self, ValidatorV1}; const TOTAL_VOTING_POWER: u64 = 10_000; @@ -68,7 +68,7 @@ module iota_system::voting_power_tests { scenario.end(); } - fun get_voting_power(validators: &vector): vector { + fun get_voting_power(validators: &vector): vector { let mut result = vector[]; let mut i = 0; let len = validators.length(); diff --git a/crates/iota-framework/packages_compiled/iota-system b/crates/iota-framework/packages_compiled/iota-system index 43d29152924..afbcca47633 100644 Binary files a/crates/iota-framework/packages_compiled/iota-system and b/crates/iota-framework/packages_compiled/iota-system differ diff --git a/crates/iota-framework/published_api.txt b/crates/iota-framework/published_api.txt index 7c4c8a77eca..8bd50d6ea10 100644 --- a/crates/iota-framework/published_api.txt +++ b/crates/iota-framework/published_api.txt @@ -16,7 +16,7 @@ new_unverified_validator_operation_cap_and_transfer new_from_unverified public(package) fun 0x3::validator_cap -StakingPool +StakingPoolV1 public struct 0x3::staking_pool PoolTokenExchangeRate @@ -124,10 +124,10 @@ initial_exchange_rate check_balance_invariants fun 0x3::staking_pool -ValidatorMetadata +ValidatorMetadataV1 public struct 0x3::validator -Validator +ValidatorV1 public struct 0x3::validator StakingRequestEvent @@ -358,10 +358,7 @@ get_staking_pool_ref new_from_metadata fun 0x3::validator -VotingPowerInfo - public struct - 0x3::voting_power -VotingPowerInfoV2 +VotingPowerInfoV1 public struct 0x3::voting_power set_voting_power @@ -391,7 +388,7 @@ total_voting_power quorum_threshold public fun 0x3::voting_power -ValidatorWrapper +Validator public struct 0x3::validator_wrapper create_v1 @@ -409,13 +406,10 @@ upgrade_to_latest version fun 0x3::validator_wrapper -ValidatorSet - public struct - 0x3::validator_set -ValidatorEpochInfoEvent +ValidatorSetV1 public struct 0x3::validator_set -ValidatorEpochInfoEventV2 +ValidatorEpochInfoEventV1 public struct 0x3::validator_set ValidatorJoinEvent @@ -604,7 +598,7 @@ is_inactive_validator active_validator_addresses public(package) fun 0x3::validator_set -StorageFund +StorageFundV1 public struct 0x3::storage_fund new @@ -619,19 +613,13 @@ total_object_storage_rebates total_balance public fun 0x3::storage_fund -SystemParameters +SystemParametersV1 public struct 0x3::iota_system_state_inner -SystemParametersV2 +IotaSystemStateV1 public struct 0x3::iota_system_state_inner -IotaSystemStateInner - public struct - 0x3::iota_system_state_inner -IotaSystemStateInnerV2 - public struct - 0x3::iota_system_state_inner -SystemEpochInfoEvent +SystemEpochInfoEventV1 public struct 0x3::iota_system_state_inner create @@ -640,9 +628,6 @@ create create_system_parameters public(package) fun 0x3::iota_system_state_inner -v1_to_v2 - public(package) fun - 0x3::iota_system_state_inner request_add_validator_candidate public(package) fun 0x3::iota_system_state_inner diff --git a/crates/iota-genesis-builder/src/lib.rs b/crates/iota-genesis-builder/src/lib.rs index 9ae05e5420a..27f77ebf443 100644 --- a/crates/iota-genesis-builder/src/lib.rs +++ b/crates/iota-genesis-builder/src/lib.rs @@ -463,9 +463,9 @@ impl Builder { } = self.parameters.to_genesis_chain_parameters(); // In non-testing code, genesis type must always be V1. + #[allow(clippy::infallible_destructuring_match)] let system_state = match unsigned_genesis.iota_system_object() { IotaSystemState::V1(inner) => inner, - IotaSystemState::V2(_) => unreachable!(), #[cfg(msim)] _ => { // Types other than V1 used in simtests do not need to be validated. diff --git a/crates/iota-graphql-e2e-tests/tests/available_range/available_range.exp b/crates/iota-graphql-e2e-tests/tests/available_range/available_range.exp index 91a523e5192..72c268bd59b 100644 --- a/crates/iota-graphql-e2e-tests/tests/available_range/available_range.exp +++ b/crates/iota-graphql-e2e-tests/tests/available_range/available_range.exp @@ -6,20 +6,20 @@ Response: { "data": { "availableRange": { "first": { - "digest": "Sb7RwyYJREvie56PXLBzn5veDf351hGqoGCkJAehQa1", + "digest": "DKptbXKz2pt5EXvcnVmbuGjqCGx7B7iiEw4D4kbiafsd", "sequenceNumber": 0 }, "last": { - "digest": "Sb7RwyYJREvie56PXLBzn5veDf351hGqoGCkJAehQa1", + "digest": "DKptbXKz2pt5EXvcnVmbuGjqCGx7B7iiEw4D4kbiafsd", "sequenceNumber": 0 } }, "first": { - "digest": "Sb7RwyYJREvie56PXLBzn5veDf351hGqoGCkJAehQa1", + "digest": "DKptbXKz2pt5EXvcnVmbuGjqCGx7B7iiEw4D4kbiafsd", "sequenceNumber": 0 }, "last": { - "digest": "Sb7RwyYJREvie56PXLBzn5veDf351hGqoGCkJAehQa1", + "digest": "DKptbXKz2pt5EXvcnVmbuGjqCGx7B7iiEw4D4kbiafsd", "sequenceNumber": 0 } } @@ -39,20 +39,20 @@ Response: { "data": { "availableRange": { "first": { - "digest": "Sb7RwyYJREvie56PXLBzn5veDf351hGqoGCkJAehQa1", + "digest": "DKptbXKz2pt5EXvcnVmbuGjqCGx7B7iiEw4D4kbiafsd", "sequenceNumber": 0 }, "last": { - "digest": "GrKNuuTApsop3VvEpBpbjsQG6wxbXvdxpKfbe8zC94MW", + "digest": "3L1P3y1CaxBwfBnGUurLVuC1iMUGrsAbE4hrizUMLsV2", "sequenceNumber": 2 } }, "first": { - "digest": "Sb7RwyYJREvie56PXLBzn5veDf351hGqoGCkJAehQa1", + "digest": "DKptbXKz2pt5EXvcnVmbuGjqCGx7B7iiEw4D4kbiafsd", "sequenceNumber": 0 }, "last": { - "digest": "GrKNuuTApsop3VvEpBpbjsQG6wxbXvdxpKfbe8zC94MW", + "digest": "3L1P3y1CaxBwfBnGUurLVuC1iMUGrsAbE4hrizUMLsV2", "sequenceNumber": 2 } } diff --git a/crates/iota-graphql-e2e-tests/tests/call/dynamic_fields.exp b/crates/iota-graphql-e2e-tests/tests/call/dynamic_fields.exp index 15dcf621387..ac5febe53b2 100644 --- a/crates/iota-graphql-e2e-tests/tests/call/dynamic_fields.exp +++ b/crates/iota-graphql-e2e-tests/tests/call/dynamic_fields.exp @@ -41,12 +41,12 @@ Response: { { "name": { "type": { - "repr": "u64" + "repr": "bool" }, "data": { - "Number": "0" + "Bool": false }, - "bcs": "AAAAAAAAAAA=" + "bcs": "AA==" }, "value": { "__typename": "MoveValue" @@ -55,40 +55,40 @@ Response: { { "name": { "type": { - "repr": "u64" + "repr": "vector" }, "data": { - "Number": "0" + "Vector": [] }, - "bcs": "AAAAAAAAAAA=" + "bcs": "AA==" }, "value": { - "__typename": "MoveObject" + "__typename": "MoveValue" } }, { "name": { "type": { - "repr": "vector" + "repr": "u64" }, "data": { - "Vector": [] + "Number": "0" }, - "bcs": "AA==" + "bcs": "AAAAAAAAAAA=" }, "value": { - "__typename": "MoveValue" + "__typename": "MoveObject" } }, { "name": { "type": { - "repr": "bool" + "repr": "u64" }, "data": { - "Bool": false + "Number": "0" }, - "bcs": "AA==" + "bcs": "AAAAAAAAAAA=" }, "value": { "__typename": "MoveValue" @@ -121,12 +121,12 @@ Response: { { "name": { "type": { - "repr": "u64" + "repr": "bool" }, "data": { - "Number": "0" + "Bool": false }, - "bcs": "AAAAAAAAAAA=" + "bcs": "AA==" }, "value": { "__typename": "MoveValue" @@ -135,40 +135,40 @@ Response: { { "name": { "type": { - "repr": "u64" + "repr": "vector" }, "data": { - "Number": "0" + "Vector": [] }, - "bcs": "AAAAAAAAAAA=" + "bcs": "AA==" }, "value": { - "__typename": "MoveObject" + "__typename": "MoveValue" } }, { "name": { "type": { - "repr": "vector" + "repr": "u64" }, "data": { - "Vector": [] + "Number": "0" }, - "bcs": "AA==" + "bcs": "AAAAAAAAAAA=" }, "value": { - "__typename": "MoveValue" + "__typename": "MoveObject" } }, { "name": { "type": { - "repr": "bool" + "repr": "u64" }, "data": { - "Bool": false + "Number": "0" }, - "bcs": "AA==" + "bcs": "AAAAAAAAAAA=" }, "value": { "__typename": "MoveValue" @@ -190,17 +190,17 @@ Response: { { "name": { "type": { - "repr": "u64" + "repr": "bool" }, "data": { - "Number": "0" + "Bool": false }, - "bcs": "AAAAAAAAAAA=" + "bcs": "AA==" }, "value": { - "bcs": "AAAAAAAAAAA=", + "bcs": "AgAAAAAAAAA=", "data": { - "Number": "0" + "Number": "2" }, "__typename": "MoveValue" } @@ -208,49 +208,49 @@ Response: { { "name": { "type": { - "repr": "u64" + "repr": "vector" }, "data": { - "Number": "0" + "Vector": [] }, - "bcs": "AAAAAAAAAAA=" + "bcs": "AA==" }, "value": { - "__typename": "MoveObject" + "bcs": "AQAAAAAAAAA=", + "data": { + "Number": "1" + }, + "__typename": "MoveValue" } }, { "name": { "type": { - "repr": "vector" + "repr": "u64" }, "data": { - "Vector": [] + "Number": "0" }, - "bcs": "AA==" + "bcs": "AAAAAAAAAAA=" }, "value": { - "bcs": "AQAAAAAAAAA=", - "data": { - "Number": "1" - }, - "__typename": "MoveValue" + "__typename": "MoveObject" } }, { "name": { "type": { - "repr": "bool" + "repr": "u64" }, "data": { - "Bool": false + "Number": "0" }, - "bcs": "AA==" + "bcs": "AAAAAAAAAAA=" }, "value": { - "bcs": "AgAAAAAAAAA=", + "bcs": "AAAAAAAAAAA=", "data": { - "Number": "2" + "Number": "0" }, "__typename": "MoveValue" } diff --git a/crates/iota-graphql-e2e-tests/tests/call/simple.exp b/crates/iota-graphql-e2e-tests/tests/call/simple.exp index 7e772c87857..79734bb008c 100644 --- a/crates/iota-graphql-e2e-tests/tests/call/simple.exp +++ b/crates/iota-graphql-e2e-tests/tests/call/simple.exp @@ -25,13 +25,15 @@ task 4, line 32: //# view-object 0,0 Owner: Account Address ( validator_0 ) Version: 1 -Contents: iota_system::validator_cap::UnverifiedValidatorOperationCap { +Contents: iota::coin::Coin { id: iota::object::UID { id: iota::object::ID { bytes: fake(0,0), }, }, - authorizer_validator_address: validator_0, + balance: iota::balance::Balance { + value: 30000000000000000u64, + }, } task 5, line 34: @@ -75,7 +77,7 @@ Epoch advanced: 5 task 10, line 44: //# view-checkpoint -CheckpointSummary { epoch: 5, seq: 10, content_digest: 9X2eEhaTREKQbXGbHrnnmvTm4TZfhhY5H6rUcecft8bX, +CheckpointSummary { epoch: 5, seq: 10, content_digest: 8C7boJBvJAis4x87RcLdUwsotz5nszRSDKNqwSRBrJ2X, epoch_rolling_gas_cost_summary: GasCostSummary { computation_cost: 0, storage_cost: 0, storage_rebate: 0, non_refundable_storage_fee: 0 }} task 11, lines 46-51: @@ -153,8 +155,8 @@ Response: { "edges": [ { "node": { - "address": "0x6273faa79d73a191d238a3bdcc2b3c11eb976980b296d22d410f95c0f61d2fde", - "digest": "121p5YAKxtozkekSFdYPAoFpViqUnAztxspya851dx9M", + "address": "0xc2e5075e25108da183a2ba97812d32c6d0a4793ec67bc5db94d90047a0f70a3d", + "digest": "AFarGPHjHVA9txUxCPKeoZtESimtPcN3nymwVYYWwBwJ", "owner": { "__typename": "AddressOwner" } @@ -180,8 +182,8 @@ Response: { "edges": [ { "node": { - "address": "0x6273faa79d73a191d238a3bdcc2b3c11eb976980b296d22d410f95c0f61d2fde", - "digest": "121p5YAKxtozkekSFdYPAoFpViqUnAztxspya851dx9M", + "address": "0xc2e5075e25108da183a2ba97812d32c6d0a4793ec67bc5db94d90047a0f70a3d", + "digest": "AFarGPHjHVA9txUxCPKeoZtESimtPcN3nymwVYYWwBwJ", "owner": { "__typename": "AddressOwner" } @@ -195,8 +197,8 @@ Response: { "edges": [ { "node": { - "address": "0x0aa69d72003801ab057e567938016c0f832f1516937fc84a8b5c11ba06c06815", - "digest": "8NvJsVTkKKDJgavep2F65Aff6gJmdWpxJJ7Hpe1dTZ7e", + "address": "0x26bf0f03edd09bb3f862e13cec014d17c26dd739d2563d9c704aa8d206301df2", + "digest": "3gSuJbZMZS3HxsjwJqf1mmxmuqJJ97DYD1HEmahVJwhH", "owner": { "__typename": "AddressOwner" } @@ -204,8 +206,8 @@ Response: { }, { "node": { - "address": "0x26bf0f03edd09bb3f862e13cec014d17c26dd739d2563d9c704aa8d206301df2", - "digest": "qm9zxqHuMpn3adTZR7Hw4kx2E5cAApBrNZcCYMTj4q4", + "address": "0x3442446f02377d1025b211e51564e4f1c9a46845ccad733beeb06180d3f66c31", + "digest": "9qvFEYrKWnQKp7pVwQwgRs4wr1JpUYjQG4rUT631cXzh", "owner": { "__typename": "AddressOwner" } @@ -213,8 +215,8 @@ Response: { }, { "node": { - "address": "0x31e3256cfe19704fd29c7e8a8d0030b2d6101b8c04668ead7bf7d38257d9e002", - "digest": "FXQKdY2oYvWnDGs3L2EuPYSYupHC8yhcsWBTtGP12DBr", + "address": "0x3c88cad5799a8da0467b8456a7429a97e7c141cfcf25f02faf51aa8cb4840461", + "digest": "9N3zxpXit5LCm3V9rbBxH4z1UBRw9ra1gdzwDW9aHs3i", "owner": { "__typename": "AddressOwner" } @@ -222,8 +224,8 @@ Response: { }, { "node": { - "address": "0x3442446f02377d1025b211e51564e4f1c9a46845ccad733beeb06180d3f66c31", - "digest": "GuVwJJNsKJwzmufHJCmPMW27fYZf2JNS2SNT3gi1XSgj", + "address": "0x5d9ebd2a8afda720f1e14510e836f0a7f2d06721edbe2dc17f1da09f8e041102", + "digest": "BiyEUGtqjGUiTvS4cGqdEmY2Nux8PDRN92DixGRjjKav", "owner": { "__typename": "AddressOwner" } @@ -231,8 +233,8 @@ Response: { }, { "node": { - "address": "0x3c88cad5799a8da0467b8456a7429a97e7c141cfcf25f02faf51aa8cb4840461", - "digest": "abMq2H3FqVggiupt3CknW1YNEKFZdYGTZNu7XpU7YsX", + "address": "0x631e1039ece5a1cfba91d8cacc6db672855259d30f4a9f26f6f9fa27779579a3", + "digest": "D8nTeQxbVWB5T6e7aUeFEkeg1YMt9joWfGhdHArfR9KD", "owner": { "__typename": "AddressOwner" } @@ -240,8 +242,8 @@ Response: { }, { "node": { - "address": "0x847c914d647e7387d7cea4db5ad8fefeffe66773635804a991dfd4385fab6a97", - "digest": "HpzDcE6Fz6Nbk1KNhY1c1qU5QxCAaHXzFA1hfYfhFMHz", + "address": "0x6793f0b1d3e3dc874b493df636a05bf09df73c97e0d796c2bac680e91b6e9fbd", + "digest": "FUn7hApxv3ufm1oZPg6JWsLKT8N8oKbZftDzTvqPXDZd", "owner": { "__typename": "AddressOwner" } @@ -249,8 +251,8 @@ Response: { }, { "node": { - "address": "0x892836945e37c3a48c0dde074d3a079a50dfc47c1fbde03d7409064340b1f743", - "digest": "6saYWQXDNUMksgPTxBkir1ZHoh6L6A1sXJ14CTTTPLkx", + "address": "0x7a5b205a60f96c06d4022771144ab858b04002a51918285efa6002f9533326e3", + "digest": "69sGWwst8WwiRh5Ne8cwC9LS1dYFoWUf6y1vLsszLccr", "owner": { "__typename": "AddressOwner" } @@ -258,8 +260,8 @@ Response: { }, { "node": { - "address": "0xa79cc544021a721176cdc4497728ec35a5311b8ff0aa293a5d29c0d32cb56056", - "digest": "844BRJc3iC63fki2xFCUuVwTJead6GqviJHFvgGmxyj5", + "address": "0x847c914d647e7387d7cea4db5ad8fefeffe66773635804a991dfd4385fab6a97", + "digest": "H2hX9mXEsdhvE3JB5js15D37uMthdFiTiL8DMcFrXnKZ", "owner": { "__typename": "AddressOwner" } @@ -267,8 +269,8 @@ Response: { }, { "node": { - "address": "0xab2415a43bf8f72193ec765f63af9cf7705bb3a312b0a14f1332be3f74d81c58", - "digest": "6p1wpzeYh47gcC9FC22Po8N1wCHMEyaZJwB4QzLRdcFo", + "address": "0xa79cc544021a721176cdc4497728ec35a5311b8ff0aa293a5d29c0d32cb56056", + "digest": "GnUXZGtU8tSukrAnZs8s3uLPJQbDGbU9LNLhQHWzodDw", "owner": { "__typename": "AddressOwner" } @@ -277,7 +279,7 @@ Response: { { "node": { "address": "0xac9c2e11aebecd35b4cb15802ca6ad5e64d320204149187ba646a16d07a4934d", - "digest": "35hWuW17ahJAyBFSWHZH2f8LNNDTF4mVT362X7FSyhJ6", + "digest": "9bFmqesBC3jaAcnXiFcuhrp5JJXKo76RShWxKuYBEepy", "owner": { "__typename": "AddressOwner" } @@ -285,8 +287,8 @@ Response: { }, { "node": { - "address": "0xb21c0b03871456040643740e238d03bde38de240d7b17055f4670777a19f07b8", - "digest": "HRC6wHwgsx4WmFhWVAJSDAMMAFoVZtGKSWrv78QDrzxn", + "address": "0xaed211bdefe57090cd0f243a9c4b3c4c0f7838304362250da740665cca37de18", + "digest": "35iGwEYbKF8QURtt7poLvhP4gvYdnNsGg2VZ7fSAGBrB", "owner": { "__typename": "AddressOwner" } @@ -294,8 +296,8 @@ Response: { }, { "node": { - "address": "0xfb29acaee47f4cf6dfd7d21773f74fb65f842e9483b194b06bf83f91c0460bf3", - "digest": "CsCUE4uQeGjvUMAAFkh1sh2rfLfLdBXJHy7aBv1TfuPo", + "address": "0xb21c0b03871456040643740e238d03bde38de240d7b17055f4670777a19f07b8", + "digest": "D5fLc9Yevxrr2SKRFZsM43zLXG4vuH3VGdXwGdx5ScaT", "owner": { "__typename": "AddressOwner" } diff --git a/crates/iota-graphql-e2e-tests/tests/consistency/balances.exp b/crates/iota-graphql-e2e-tests/tests/consistency/balances.exp index cd7e0694d83..7bb6a6e629c 100644 --- a/crates/iota-graphql-e2e-tests/tests/consistency/balances.exp +++ b/crates/iota-graphql-e2e-tests/tests/consistency/balances.exp @@ -80,7 +80,7 @@ Response: { }, { "coinType": { - "repr": "0xe8ee7be6dbe0973ef635dc6515beaa862a9597be976c26dbaf1034e593b3c85f::fake::FAKE" + "repr": "0x84f9be4b6e49b87bb7eb2f2e16298b7c8e1a2d60fdd9730e32405b7b46a5df70::fake::FAKE" }, "coinObjectCount": 3, "totalBalance": "700" @@ -103,7 +103,7 @@ Response: { { "sender": { "fakeCoinBalance": { - "totalBalance": "500" + "totalBalance": "600" }, "allBalances": { "nodes": [ @@ -116,10 +116,10 @@ Response: { }, { "coinType": { - "repr": "0xe8ee7be6dbe0973ef635dc6515beaa862a9597be976c26dbaf1034e593b3c85f::fake::FAKE" + "repr": "0x84f9be4b6e49b87bb7eb2f2e16298b7c8e1a2d60fdd9730e32405b7b46a5df70::fake::FAKE" }, "coinObjectCount": 2, - "totalBalance": "500" + "totalBalance": "600" } ] } @@ -139,7 +139,7 @@ Response: { { "sender": { "fakeCoinBalance": { - "totalBalance": "200" + "totalBalance": "300" }, "allBalances": { "nodes": [ @@ -152,10 +152,10 @@ Response: { }, { "coinType": { - "repr": "0xe8ee7be6dbe0973ef635dc6515beaa862a9597be976c26dbaf1034e593b3c85f::fake::FAKE" + "repr": "0x84f9be4b6e49b87bb7eb2f2e16298b7c8e1a2d60fdd9730e32405b7b46a5df70::fake::FAKE" }, "coinObjectCount": 1, - "totalBalance": "200" + "totalBalance": "300" } ] } @@ -196,7 +196,7 @@ Response: { }, { "coinType": { - "repr": "0xe8ee7be6dbe0973ef635dc6515beaa862a9597be976c26dbaf1034e593b3c85f::fake::FAKE" + "repr": "0x84f9be4b6e49b87bb7eb2f2e16298b7c8e1a2d60fdd9730e32405b7b46a5df70::fake::FAKE" }, "coinObjectCount": 3, "totalBalance": "700" @@ -219,7 +219,7 @@ Response: { { "sender": { "fakeCoinBalance": { - "totalBalance": "500" + "totalBalance": "600" }, "allBalances": { "nodes": [ @@ -232,10 +232,10 @@ Response: { }, { "coinType": { - "repr": "0xe8ee7be6dbe0973ef635dc6515beaa862a9597be976c26dbaf1034e593b3c85f::fake::FAKE" + "repr": "0x84f9be4b6e49b87bb7eb2f2e16298b7c8e1a2d60fdd9730e32405b7b46a5df70::fake::FAKE" }, "coinObjectCount": 2, - "totalBalance": "500" + "totalBalance": "600" } ] } @@ -255,7 +255,7 @@ Response: { { "sender": { "fakeCoinBalance": { - "totalBalance": "200" + "totalBalance": "300" }, "allBalances": { "nodes": [ @@ -268,10 +268,10 @@ Response: { }, { "coinType": { - "repr": "0xe8ee7be6dbe0973ef635dc6515beaa862a9597be976c26dbaf1034e593b3c85f::fake::FAKE" + "repr": "0x84f9be4b6e49b87bb7eb2f2e16298b7c8e1a2d60fdd9730e32405b7b46a5df70::fake::FAKE" }, "coinObjectCount": 1, - "totalBalance": "200" + "totalBalance": "300" } ] } @@ -334,7 +334,7 @@ Response: { { "sender": { "fakeCoinBalance": { - "totalBalance": "500" + "totalBalance": "600" }, "allBalances": { "nodes": [ @@ -347,10 +347,10 @@ Response: { }, { "coinType": { - "repr": "0xe8ee7be6dbe0973ef635dc6515beaa862a9597be976c26dbaf1034e593b3c85f::fake::FAKE" + "repr": "0x84f9be4b6e49b87bb7eb2f2e16298b7c8e1a2d60fdd9730e32405b7b46a5df70::fake::FAKE" }, "coinObjectCount": 2, - "totalBalance": "500" + "totalBalance": "600" } ] } @@ -370,7 +370,7 @@ Response: { { "sender": { "fakeCoinBalance": { - "totalBalance": "200" + "totalBalance": "300" }, "allBalances": { "nodes": [ @@ -383,10 +383,10 @@ Response: { }, { "coinType": { - "repr": "0xe8ee7be6dbe0973ef635dc6515beaa862a9597be976c26dbaf1034e593b3c85f::fake::FAKE" + "repr": "0x84f9be4b6e49b87bb7eb2f2e16298b7c8e1a2d60fdd9730e32405b7b46a5df70::fake::FAKE" }, "coinObjectCount": 1, - "totalBalance": "200" + "totalBalance": "300" } ] } diff --git a/crates/iota-graphql-e2e-tests/tests/consistency/checkpoints/transaction_blocks.exp b/crates/iota-graphql-e2e-tests/tests/consistency/checkpoints/transaction_blocks.exp index f652aea58ac..7cf21dbc53d 100644 --- a/crates/iota-graphql-e2e-tests/tests/consistency/checkpoints/transaction_blocks.exp +++ b/crates/iota-graphql-e2e-tests/tests/consistency/checkpoints/transaction_blocks.exp @@ -94,12 +94,12 @@ Response: { { "cursor": "eyJjIjozLCJ0IjoyLCJpIjpmYWxzZX0", "node": { - "digest": "3Wu2rNcM39pocoovpHUXZrWtwQXn8ZXAGpwrU7GthLLD", + "digest": "79od1gfpa4bdobeR94ZQ38ea2SbKVrnYo4KiRpUKZKyB", "sender": { "objects": { "edges": [ { - "cursor": "IOuXfIr/MFNZLw/UcBw1yb4Asy3a7l9mjzGLhiX0TNM2AwAAAAAAAAA=" + "cursor": "IK/PYAxfnGBPTvQuJjjAlDX1bI4ft+Ho3hD6OQmoySXSAwAAAAAAAAA=" } ] } @@ -109,12 +109,12 @@ Response: { { "cursor": "eyJjIjozLCJ0IjozLCJpIjpmYWxzZX0", "node": { - "digest": "5Fx8EKmMoiHb59rVr2ch64EgLyvs9SWhuUHq6x3HAx3T", + "digest": "7qGUBfHDs1CziLgVJBXamBawVtztiyp2sAPdaRWiPNT1", "sender": { "objects": { "edges": [ { - "cursor": "IOuXfIr/MFNZLw/UcBw1yb4Asy3a7l9mjzGLhiX0TNM2AwAAAAAAAAA=" + "cursor": "IK/PYAxfnGBPTvQuJjjAlDX1bI4ft+Ho3hD6OQmoySXSAwAAAAAAAAA=" } ] } @@ -124,12 +124,12 @@ Response: { { "cursor": "eyJjIjozLCJ0Ijo0LCJpIjpmYWxzZX0", "node": { - "digest": "DvNBuuqGugb9p76oMb1jLa6MdAv7mT184x69bGKC2rQw", + "digest": "BMAW5GS7peWfXNwjcNKYfRqWDJ5Mb7eY61o1KMcozhFG", "sender": { "objects": { "edges": [ { - "cursor": "IOuXfIr/MFNZLw/UcBw1yb4Asy3a7l9mjzGLhiX0TNM2AwAAAAAAAAA=" + "cursor": "IK/PYAxfnGBPTvQuJjjAlDX1bI4ft+Ho3hD6OQmoySXSAwAAAAAAAAA=" } ] } @@ -139,12 +139,12 @@ Response: { { "cursor": "eyJjIjozLCJ0Ijo1LCJpIjpmYWxzZX0", "node": { - "digest": "ERSRy9F3o39NCDRWeDVz5AgBGZPmaCdXzzJ6tjd8eY7k", + "digest": "6dR6sJWFBCVAf65zvqJAZBwViUT1PdjmgWmPckqWHtpg", "sender": { "objects": { "edges": [ { - "cursor": "IOuXfIr/MFNZLw/UcBw1yb4Asy3a7l9mjzGLhiX0TNM2AwAAAAAAAAA=" + "cursor": "IK/PYAxfnGBPTvQuJjjAlDX1bI4ft+Ho3hD6OQmoySXSAwAAAAAAAAA=" } ] } @@ -161,12 +161,12 @@ Response: { { "cursor": "eyJjIjozLCJ0Ijo2LCJpIjpmYWxzZX0", "node": { - "digest": "2uLirA5sxREeS1UHEKCJWeoMv2R1MKCUiiep9Q6s7WA6", + "digest": "5mUu9bxNaotcEsssawXpQWZ5Rd2RkjbssbZHy4YqP6jj", "sender": { "objects": { "edges": [ { - "cursor": "IOuXfIr/MFNZLw/UcBw1yb4Asy3a7l9mjzGLhiX0TNM2AwAAAAAAAAA=" + "cursor": "IK/PYAxfnGBPTvQuJjjAlDX1bI4ft+Ho3hD6OQmoySXSAwAAAAAAAAA=" } ] } @@ -176,12 +176,12 @@ Response: { { "cursor": "eyJjIjozLCJ0Ijo3LCJpIjpmYWxzZX0", "node": { - "digest": "4HgxdMoiQdZbLrd7ycQ3csPtccNPvr9BZW67ykV7NRk6", + "digest": "26L1PsnhdXmQHEgRiqw9WTMmFZy8CJUjta7yGuuvH7DD", "sender": { "objects": { "edges": [ { - "cursor": "IOuXfIr/MFNZLw/UcBw1yb4Asy3a7l9mjzGLhiX0TNM2AwAAAAAAAAA=" + "cursor": "IK/PYAxfnGBPTvQuJjjAlDX1bI4ft+Ho3hD6OQmoySXSAwAAAAAAAAA=" } ] } @@ -191,12 +191,12 @@ Response: { { "cursor": "eyJjIjozLCJ0Ijo4LCJpIjpmYWxzZX0", "node": { - "digest": "d9yohmp3svrBRKZjbfv7Gn5TbCrmspbqis2wy76ES1M", + "digest": "9Rztd6zgt6r1kZ5hUPALhi8K2ZXBBDj8d2aF3cemSZCP", "sender": { "objects": { "edges": [ { - "cursor": "IOuXfIr/MFNZLw/UcBw1yb4Asy3a7l9mjzGLhiX0TNM2AwAAAAAAAAA=" + "cursor": "IK/PYAxfnGBPTvQuJjjAlDX1bI4ft+Ho3hD6OQmoySXSAwAAAAAAAAA=" } ] } @@ -213,12 +213,12 @@ Response: { { "cursor": "eyJjIjozLCJ0Ijo5LCJpIjpmYWxzZX0", "node": { - "digest": "ExuPheKtkWpsGKjy7HuYFUWjsGqftVXNXyyu8XQUjro5", + "digest": "2RUSFSVNTC7FniEbnzm3g97tp3hbypt5GGWmJGFPnmDV", "sender": { "objects": { "edges": [ { - "cursor": "IOuXfIr/MFNZLw/UcBw1yb4Asy3a7l9mjzGLhiX0TNM2AwAAAAAAAAA=" + "cursor": "IK/PYAxfnGBPTvQuJjjAlDX1bI4ft+Ho3hD6OQmoySXSAwAAAAAAAAA=" } ] } @@ -228,12 +228,12 @@ Response: { { "cursor": "eyJjIjozLCJ0IjoxMCwiaSI6ZmFsc2V9", "node": { - "digest": "GFdCwVbseLpFVe3sX91EkkAHJm2hXXVM3LH4FZu1gn9K", + "digest": "3E7sv74JFwPZziRo1JykjSBZ6TG2FNGZGdTqRwbWSust", "sender": { "objects": { "edges": [ { - "cursor": "IOuXfIr/MFNZLw/UcBw1yb4Asy3a7l9mjzGLhiX0TNM2AwAAAAAAAAA=" + "cursor": "IK/PYAxfnGBPTvQuJjjAlDX1bI4ft+Ho3hD6OQmoySXSAwAAAAAAAAA=" } ] } diff --git a/crates/iota-graphql-e2e-tests/tests/consistency/coins.exp b/crates/iota-graphql-e2e-tests/tests/consistency/coins.exp index 3c22209efb3..b5156d37581 100644 --- a/crates/iota-graphql-e2e-tests/tests/consistency/coins.exp +++ b/crates/iota-graphql-e2e-tests/tests/consistency/coins.exp @@ -33,7 +33,7 @@ Response: { "queryCoinsAtLatest": { "edges": [ { - "cursor": "ICiav5I6Mkx08X0VmoZKIJ0awF2KpVcGFefQ4GWueq9jAgAAAAAAAAA=", + "cursor": "INF4y6RgI+x6+uilTvYHZ19okSbPHT/Td7qiwWLoply5AgAAAAAAAAA=", "node": { "consistentStateForEachCoin": { "owner": { @@ -41,37 +41,37 @@ Response: { "coins": { "edges": [ { - "cursor": "ICiav5I6Mkx08X0VmoZKIJ0awF2KpVcGFefQ4GWueq9jAgAAAAAAAAA=", + "cursor": "INF4y6RgI+x6+uilTvYHZ19okSbPHT/Td7qiwWLoply5AgAAAAAAAAA=", "node": { "contents": { "json": { - "id": "0x289abf923a324c74f17d159a864a209d1ac05d8aa5570615e7d0e065ae7aaf63", + "id": "0xd178cba46023ec7afae8a54ef607675f689126cf1d3fd377baa2c162e8a65cb9", "balance": { - "value": "100100" + "value": "100200" } } } } }, { - "cursor": "IKQYR4gBIlqmEkXHMhZsUUbfKoX8aufbPgILwCO/Sly9AgAAAAAAAAA=", + "cursor": "IOfJiINYZ0h4ktDswip1pPKO10xxW2+MxPXoCXaG0jjHAgAAAAAAAAA=", "node": { "contents": { "json": { - "id": "0xa418478801225aa61245c732166c5146df2a85fc6ae7db3e020bc023bf4a5cbd", + "id": "0xe7c988835867487892d0ecc22a75a4f28ed74c715b6f8cc4f5e8097686d238c7", "balance": { - "value": "200" + "value": "100" } } } } }, { - "cursor": "IOtyLmahCDl5xXyOjB0WMqX9cUF4/ZkicypBnpx9OxxlAgAAAAAAAAA=", + "cursor": "IPj4cRR2GNmdRMDkAa374gC9VjY1lCd4DFcmTQZIYn+eAgAAAAAAAAA=", "node": { "contents": { "json": { - "id": "0xeb722e66a1083979c57c8e8c1d1632a5fd714178fd9922732a419e9c7d3b1c65", + "id": "0xf8f871147618d99d44c0e401adfbe200bd5636359427780c57264d0648627f9e", "balance": { "value": "300" } @@ -85,16 +85,16 @@ Response: { }, "contents": { "json": { - "id": "0x289abf923a324c74f17d159a864a209d1ac05d8aa5570615e7d0e065ae7aaf63", + "id": "0xd178cba46023ec7afae8a54ef607675f689126cf1d3fd377baa2c162e8a65cb9", "balance": { - "value": "100100" + "value": "100200" } } } } }, { - "cursor": "IKQYR4gBIlqmEkXHMhZsUUbfKoX8aufbPgILwCO/Sly9AgAAAAAAAAA=", + "cursor": "IOfJiINYZ0h4ktDswip1pPKO10xxW2+MxPXoCXaG0jjHAgAAAAAAAAA=", "node": { "consistentStateForEachCoin": { "owner": { @@ -102,37 +102,37 @@ Response: { "coins": { "edges": [ { - "cursor": "ICiav5I6Mkx08X0VmoZKIJ0awF2KpVcGFefQ4GWueq9jAgAAAAAAAAA=", + "cursor": "INF4y6RgI+x6+uilTvYHZ19okSbPHT/Td7qiwWLoply5AgAAAAAAAAA=", "node": { "contents": { "json": { - "id": "0x289abf923a324c74f17d159a864a209d1ac05d8aa5570615e7d0e065ae7aaf63", + "id": "0xd178cba46023ec7afae8a54ef607675f689126cf1d3fd377baa2c162e8a65cb9", "balance": { - "value": "100100" + "value": "100200" } } } } }, { - "cursor": "IKQYR4gBIlqmEkXHMhZsUUbfKoX8aufbPgILwCO/Sly9AgAAAAAAAAA=", + "cursor": "IOfJiINYZ0h4ktDswip1pPKO10xxW2+MxPXoCXaG0jjHAgAAAAAAAAA=", "node": { "contents": { "json": { - "id": "0xa418478801225aa61245c732166c5146df2a85fc6ae7db3e020bc023bf4a5cbd", + "id": "0xe7c988835867487892d0ecc22a75a4f28ed74c715b6f8cc4f5e8097686d238c7", "balance": { - "value": "200" + "value": "100" } } } } }, { - "cursor": "IOtyLmahCDl5xXyOjB0WMqX9cUF4/ZkicypBnpx9OxxlAgAAAAAAAAA=", + "cursor": "IPj4cRR2GNmdRMDkAa374gC9VjY1lCd4DFcmTQZIYn+eAgAAAAAAAAA=", "node": { "contents": { "json": { - "id": "0xeb722e66a1083979c57c8e8c1d1632a5fd714178fd9922732a419e9c7d3b1c65", + "id": "0xf8f871147618d99d44c0e401adfbe200bd5636359427780c57264d0648627f9e", "balance": { "value": "300" } @@ -146,16 +146,16 @@ Response: { }, "contents": { "json": { - "id": "0xa418478801225aa61245c732166c5146df2a85fc6ae7db3e020bc023bf4a5cbd", + "id": "0xe7c988835867487892d0ecc22a75a4f28ed74c715b6f8cc4f5e8097686d238c7", "balance": { - "value": "200" + "value": "100" } } } } }, { - "cursor": "IOtyLmahCDl5xXyOjB0WMqX9cUF4/ZkicypBnpx9OxxlAgAAAAAAAAA=", + "cursor": "IPj4cRR2GNmdRMDkAa374gC9VjY1lCd4DFcmTQZIYn+eAgAAAAAAAAA=", "node": { "consistentStateForEachCoin": { "owner": { @@ -163,37 +163,37 @@ Response: { "coins": { "edges": [ { - "cursor": "ICiav5I6Mkx08X0VmoZKIJ0awF2KpVcGFefQ4GWueq9jAgAAAAAAAAA=", + "cursor": "INF4y6RgI+x6+uilTvYHZ19okSbPHT/Td7qiwWLoply5AgAAAAAAAAA=", "node": { "contents": { "json": { - "id": "0x289abf923a324c74f17d159a864a209d1ac05d8aa5570615e7d0e065ae7aaf63", + "id": "0xd178cba46023ec7afae8a54ef607675f689126cf1d3fd377baa2c162e8a65cb9", "balance": { - "value": "100100" + "value": "100200" } } } } }, { - "cursor": "IKQYR4gBIlqmEkXHMhZsUUbfKoX8aufbPgILwCO/Sly9AgAAAAAAAAA=", + "cursor": "IOfJiINYZ0h4ktDswip1pPKO10xxW2+MxPXoCXaG0jjHAgAAAAAAAAA=", "node": { "contents": { "json": { - "id": "0xa418478801225aa61245c732166c5146df2a85fc6ae7db3e020bc023bf4a5cbd", + "id": "0xe7c988835867487892d0ecc22a75a4f28ed74c715b6f8cc4f5e8097686d238c7", "balance": { - "value": "200" + "value": "100" } } } } }, { - "cursor": "IOtyLmahCDl5xXyOjB0WMqX9cUF4/ZkicypBnpx9OxxlAgAAAAAAAAA=", + "cursor": "IPj4cRR2GNmdRMDkAa374gC9VjY1lCd4DFcmTQZIYn+eAgAAAAAAAAA=", "node": { "contents": { "json": { - "id": "0xeb722e66a1083979c57c8e8c1d1632a5fd714178fd9922732a419e9c7d3b1c65", + "id": "0xf8f871147618d99d44c0e401adfbe200bd5636359427780c57264d0648627f9e", "balance": { "value": "300" } @@ -207,7 +207,7 @@ Response: { }, "contents": { "json": { - "id": "0xeb722e66a1083979c57c8e8c1d1632a5fd714178fd9922732a419e9c7d3b1c65", + "id": "0xf8f871147618d99d44c0e401adfbe200bd5636359427780c57264d0648627f9e", "balance": { "value": "300" } @@ -221,37 +221,37 @@ Response: { "coins": { "edges": [ { - "cursor": "ICiav5I6Mkx08X0VmoZKIJ0awF2KpVcGFefQ4GWueq9jAgAAAAAAAAA=", + "cursor": "INF4y6RgI+x6+uilTvYHZ19okSbPHT/Td7qiwWLoply5AgAAAAAAAAA=", "node": { "contents": { "json": { - "id": "0x289abf923a324c74f17d159a864a209d1ac05d8aa5570615e7d0e065ae7aaf63", + "id": "0xd178cba46023ec7afae8a54ef607675f689126cf1d3fd377baa2c162e8a65cb9", "balance": { - "value": "100100" + "value": "100200" } } } } }, { - "cursor": "IKQYR4gBIlqmEkXHMhZsUUbfKoX8aufbPgILwCO/Sly9AgAAAAAAAAA=", + "cursor": "IOfJiINYZ0h4ktDswip1pPKO10xxW2+MxPXoCXaG0jjHAgAAAAAAAAA=", "node": { "contents": { "json": { - "id": "0xa418478801225aa61245c732166c5146df2a85fc6ae7db3e020bc023bf4a5cbd", + "id": "0xe7c988835867487892d0ecc22a75a4f28ed74c715b6f8cc4f5e8097686d238c7", "balance": { - "value": "200" + "value": "100" } } } } }, { - "cursor": "IOtyLmahCDl5xXyOjB0WMqX9cUF4/ZkicypBnpx9OxxlAgAAAAAAAAA=", + "cursor": "IPj4cRR2GNmdRMDkAa374gC9VjY1lCd4DFcmTQZIYn+eAgAAAAAAAAA=", "node": { "contents": { "json": { - "id": "0xeb722e66a1083979c57c8e8c1d1632a5fd714178fd9922732a419e9c7d3b1c65", + "id": "0xf8f871147618d99d44c0e401adfbe200bd5636359427780c57264d0648627f9e", "balance": { "value": "300" } @@ -272,7 +272,7 @@ Response: { "queryCoinsAtChkpt1": { "edges": [ { - "cursor": "ICiav5I6Mkx08X0VmoZKIJ0awF2KpVcGFefQ4GWueq9jAQAAAAAAAAA=", + "cursor": "INF4y6RgI+x6+uilTvYHZ19okSbPHT/Td7qiwWLoply5AQAAAAAAAAA=", "node": { "consistentStateForEachCoin": { "owner": { @@ -280,37 +280,37 @@ Response: { "coins": { "edges": [ { - "cursor": "ICiav5I6Mkx08X0VmoZKIJ0awF2KpVcGFefQ4GWueq9jAQAAAAAAAAA=", + "cursor": "INF4y6RgI+x6+uilTvYHZ19okSbPHT/Td7qiwWLoply5AQAAAAAAAAA=", "node": { "contents": { "json": { - "id": "0x289abf923a324c74f17d159a864a209d1ac05d8aa5570615e7d0e065ae7aaf63", + "id": "0xd178cba46023ec7afae8a54ef607675f689126cf1d3fd377baa2c162e8a65cb9", "balance": { - "value": "100" + "value": "200" } } } } }, { - "cursor": "IKQYR4gBIlqmEkXHMhZsUUbfKoX8aufbPgILwCO/Sly9AQAAAAAAAAA=", + "cursor": "IOfJiINYZ0h4ktDswip1pPKO10xxW2+MxPXoCXaG0jjHAQAAAAAAAAA=", "node": { "contents": { "json": { - "id": "0xa418478801225aa61245c732166c5146df2a85fc6ae7db3e020bc023bf4a5cbd", + "id": "0xe7c988835867487892d0ecc22a75a4f28ed74c715b6f8cc4f5e8097686d238c7", "balance": { - "value": "200" + "value": "100" } } } } }, { - "cursor": "IOtyLmahCDl5xXyOjB0WMqX9cUF4/ZkicypBnpx9OxxlAQAAAAAAAAA=", + "cursor": "IPj4cRR2GNmdRMDkAa374gC9VjY1lCd4DFcmTQZIYn+eAQAAAAAAAAA=", "node": { "contents": { "json": { - "id": "0xeb722e66a1083979c57c8e8c1d1632a5fd714178fd9922732a419e9c7d3b1c65", + "id": "0xf8f871147618d99d44c0e401adfbe200bd5636359427780c57264d0648627f9e", "balance": { "value": "300" } @@ -324,16 +324,16 @@ Response: { }, "contents": { "json": { - "id": "0x289abf923a324c74f17d159a864a209d1ac05d8aa5570615e7d0e065ae7aaf63", + "id": "0xd178cba46023ec7afae8a54ef607675f689126cf1d3fd377baa2c162e8a65cb9", "balance": { - "value": "100" + "value": "200" } } } } }, { - "cursor": "IKQYR4gBIlqmEkXHMhZsUUbfKoX8aufbPgILwCO/Sly9AQAAAAAAAAA=", + "cursor": "IOfJiINYZ0h4ktDswip1pPKO10xxW2+MxPXoCXaG0jjHAQAAAAAAAAA=", "node": { "consistentStateForEachCoin": { "owner": { @@ -341,37 +341,37 @@ Response: { "coins": { "edges": [ { - "cursor": "ICiav5I6Mkx08X0VmoZKIJ0awF2KpVcGFefQ4GWueq9jAQAAAAAAAAA=", + "cursor": "INF4y6RgI+x6+uilTvYHZ19okSbPHT/Td7qiwWLoply5AQAAAAAAAAA=", "node": { "contents": { "json": { - "id": "0x289abf923a324c74f17d159a864a209d1ac05d8aa5570615e7d0e065ae7aaf63", + "id": "0xd178cba46023ec7afae8a54ef607675f689126cf1d3fd377baa2c162e8a65cb9", "balance": { - "value": "100" + "value": "200" } } } } }, { - "cursor": "IKQYR4gBIlqmEkXHMhZsUUbfKoX8aufbPgILwCO/Sly9AQAAAAAAAAA=", + "cursor": "IOfJiINYZ0h4ktDswip1pPKO10xxW2+MxPXoCXaG0jjHAQAAAAAAAAA=", "node": { "contents": { "json": { - "id": "0xa418478801225aa61245c732166c5146df2a85fc6ae7db3e020bc023bf4a5cbd", + "id": "0xe7c988835867487892d0ecc22a75a4f28ed74c715b6f8cc4f5e8097686d238c7", "balance": { - "value": "200" + "value": "100" } } } } }, { - "cursor": "IOtyLmahCDl5xXyOjB0WMqX9cUF4/ZkicypBnpx9OxxlAQAAAAAAAAA=", + "cursor": "IPj4cRR2GNmdRMDkAa374gC9VjY1lCd4DFcmTQZIYn+eAQAAAAAAAAA=", "node": { "contents": { "json": { - "id": "0xeb722e66a1083979c57c8e8c1d1632a5fd714178fd9922732a419e9c7d3b1c65", + "id": "0xf8f871147618d99d44c0e401adfbe200bd5636359427780c57264d0648627f9e", "balance": { "value": "300" } @@ -385,9 +385,9 @@ Response: { }, "contents": { "json": { - "id": "0xa418478801225aa61245c732166c5146df2a85fc6ae7db3e020bc023bf4a5cbd", + "id": "0xe7c988835867487892d0ecc22a75a4f28ed74c715b6f8cc4f5e8097686d238c7", "balance": { - "value": "200" + "value": "100" } } } @@ -399,26 +399,26 @@ Response: { "coins": { "edges": [ { - "cursor": "ICiav5I6Mkx08X0VmoZKIJ0awF2KpVcGFefQ4GWueq9jAQAAAAAAAAA=", + "cursor": "INF4y6RgI+x6+uilTvYHZ19okSbPHT/Td7qiwWLoply5AQAAAAAAAAA=", "node": { "contents": { "json": { - "id": "0x289abf923a324c74f17d159a864a209d1ac05d8aa5570615e7d0e065ae7aaf63", + "id": "0xd178cba46023ec7afae8a54ef607675f689126cf1d3fd377baa2c162e8a65cb9", "balance": { - "value": "100" + "value": "200" } } } } }, { - "cursor": "IKQYR4gBIlqmEkXHMhZsUUbfKoX8aufbPgILwCO/Sly9AQAAAAAAAAA=", + "cursor": "IOfJiINYZ0h4ktDswip1pPKO10xxW2+MxPXoCXaG0jjHAQAAAAAAAAA=", "node": { "contents": { "json": { - "id": "0xa418478801225aa61245c732166c5146df2a85fc6ae7db3e020bc023bf4a5cbd", + "id": "0xe7c988835867487892d0ecc22a75a4f28ed74c715b6f8cc4f5e8097686d238c7", "balance": { - "value": "200" + "value": "100" } } } @@ -453,7 +453,7 @@ Response: { "queryCoins": { "edges": [ { - "cursor": "ICiav5I6Mkx08X0VmoZKIJ0awF2KpVcGFefQ4GWueq9jAwAAAAAAAAA=", + "cursor": "INF4y6RgI+x6+uilTvYHZ19okSbPHT/Td7qiwWLoply5AwAAAAAAAAA=", "node": { "owner": { "owner": { @@ -461,13 +461,13 @@ Response: { "coins": { "edges": [ { - "cursor": "ICiav5I6Mkx08X0VmoZKIJ0awF2KpVcGFefQ4GWueq9jAwAAAAAAAAA=", + "cursor": "INF4y6RgI+x6+uilTvYHZ19okSbPHT/Td7qiwWLoply5AwAAAAAAAAA=", "node": { "contents": { "json": { - "id": "0x289abf923a324c74f17d159a864a209d1ac05d8aa5570615e7d0e065ae7aaf63", + "id": "0xd178cba46023ec7afae8a54ef607675f689126cf1d3fd377baa2c162e8a65cb9", "balance": { - "value": "100100" + "value": "100200" } } } @@ -479,16 +479,16 @@ Response: { }, "contents": { "json": { - "id": "0x289abf923a324c74f17d159a864a209d1ac05d8aa5570615e7d0e065ae7aaf63", + "id": "0xd178cba46023ec7afae8a54ef607675f689126cf1d3fd377baa2c162e8a65cb9", "balance": { - "value": "100100" + "value": "100200" } } } } }, { - "cursor": "IKQYR4gBIlqmEkXHMhZsUUbfKoX8aufbPgILwCO/Sly9AwAAAAAAAAA=", + "cursor": "IOfJiINYZ0h4ktDswip1pPKO10xxW2+MxPXoCXaG0jjHAwAAAAAAAAA=", "node": { "owner": { "owner": { @@ -496,24 +496,24 @@ Response: { "coins": { "edges": [ { - "cursor": "IKQYR4gBIlqmEkXHMhZsUUbfKoX8aufbPgILwCO/Sly9AwAAAAAAAAA=", + "cursor": "IOfJiINYZ0h4ktDswip1pPKO10xxW2+MxPXoCXaG0jjHAwAAAAAAAAA=", "node": { "contents": { "json": { - "id": "0xa418478801225aa61245c732166c5146df2a85fc6ae7db3e020bc023bf4a5cbd", + "id": "0xe7c988835867487892d0ecc22a75a4f28ed74c715b6f8cc4f5e8097686d238c7", "balance": { - "value": "200" + "value": "100" } } } } }, { - "cursor": "IOtyLmahCDl5xXyOjB0WMqX9cUF4/ZkicypBnpx9OxxlAwAAAAAAAAA=", + "cursor": "IPj4cRR2GNmdRMDkAa374gC9VjY1lCd4DFcmTQZIYn+eAwAAAAAAAAA=", "node": { "contents": { "json": { - "id": "0xeb722e66a1083979c57c8e8c1d1632a5fd714178fd9922732a419e9c7d3b1c65", + "id": "0xf8f871147618d99d44c0e401adfbe200bd5636359427780c57264d0648627f9e", "balance": { "value": "300" } @@ -527,16 +527,16 @@ Response: { }, "contents": { "json": { - "id": "0xa418478801225aa61245c732166c5146df2a85fc6ae7db3e020bc023bf4a5cbd", + "id": "0xe7c988835867487892d0ecc22a75a4f28ed74c715b6f8cc4f5e8097686d238c7", "balance": { - "value": "200" + "value": "100" } } } } }, { - "cursor": "IOtyLmahCDl5xXyOjB0WMqX9cUF4/ZkicypBnpx9OxxlAwAAAAAAAAA=", + "cursor": "IPj4cRR2GNmdRMDkAa374gC9VjY1lCd4DFcmTQZIYn+eAwAAAAAAAAA=", "node": { "owner": { "owner": { @@ -544,24 +544,24 @@ Response: { "coins": { "edges": [ { - "cursor": "IKQYR4gBIlqmEkXHMhZsUUbfKoX8aufbPgILwCO/Sly9AwAAAAAAAAA=", + "cursor": "IOfJiINYZ0h4ktDswip1pPKO10xxW2+MxPXoCXaG0jjHAwAAAAAAAAA=", "node": { "contents": { "json": { - "id": "0xa418478801225aa61245c732166c5146df2a85fc6ae7db3e020bc023bf4a5cbd", + "id": "0xe7c988835867487892d0ecc22a75a4f28ed74c715b6f8cc4f5e8097686d238c7", "balance": { - "value": "200" + "value": "100" } } } } }, { - "cursor": "IOtyLmahCDl5xXyOjB0WMqX9cUF4/ZkicypBnpx9OxxlAwAAAAAAAAA=", + "cursor": "IPj4cRR2GNmdRMDkAa374gC9VjY1lCd4DFcmTQZIYn+eAwAAAAAAAAA=", "node": { "contents": { "json": { - "id": "0xeb722e66a1083979c57c8e8c1d1632a5fd714178fd9922732a419e9c7d3b1c65", + "id": "0xf8f871147618d99d44c0e401adfbe200bd5636359427780c57264d0648627f9e", "balance": { "value": "300" } @@ -575,7 +575,7 @@ Response: { }, "contents": { "json": { - "id": "0xeb722e66a1083979c57c8e8c1d1632a5fd714178fd9922732a419e9c7d3b1c65", + "id": "0xf8f871147618d99d44c0e401adfbe200bd5636359427780c57264d0648627f9e", "balance": { "value": "300" } @@ -589,13 +589,13 @@ Response: { "coins": { "edges": [ { - "cursor": "ICiav5I6Mkx08X0VmoZKIJ0awF2KpVcGFefQ4GWueq9jAwAAAAAAAAA=", + "cursor": "INF4y6RgI+x6+uilTvYHZ19okSbPHT/Td7qiwWLoply5AwAAAAAAAAA=", "node": { "contents": { "json": { - "id": "0x289abf923a324c74f17d159a864a209d1ac05d8aa5570615e7d0e065ae7aaf63", + "id": "0xd178cba46023ec7afae8a54ef607675f689126cf1d3fd377baa2c162e8a65cb9", "balance": { - "value": "100100" + "value": "100200" } } } @@ -608,24 +608,24 @@ Response: { "coins": { "edges": [ { - "cursor": "IKQYR4gBIlqmEkXHMhZsUUbfKoX8aufbPgILwCO/Sly9AwAAAAAAAAA=", + "cursor": "IOfJiINYZ0h4ktDswip1pPKO10xxW2+MxPXoCXaG0jjHAwAAAAAAAAA=", "node": { "contents": { "json": { - "id": "0xa418478801225aa61245c732166c5146df2a85fc6ae7db3e020bc023bf4a5cbd", + "id": "0xe7c988835867487892d0ecc22a75a4f28ed74c715b6f8cc4f5e8097686d238c7", "balance": { - "value": "200" + "value": "100" } } } } }, { - "cursor": "IOtyLmahCDl5xXyOjB0WMqX9cUF4/ZkicypBnpx9OxxlAwAAAAAAAAA=", + "cursor": "IPj4cRR2GNmdRMDkAa374gC9VjY1lCd4DFcmTQZIYn+eAwAAAAAAAAA=", "node": { "contents": { "json": { - "id": "0xeb722e66a1083979c57c8e8c1d1632a5fd714178fd9922732a419e9c7d3b1c65", + "id": "0xf8f871147618d99d44c0e401adfbe200bd5636359427780c57264d0648627f9e", "balance": { "value": "300" } @@ -658,7 +658,7 @@ Response: { "queryCoinsAtChkpt1BeforeSnapshotCatchup": { "edges": [ { - "cursor": "ICiav5I6Mkx08X0VmoZKIJ0awF2KpVcGFefQ4GWueq9jAQAAAAAAAAA=", + "cursor": "INF4y6RgI+x6+uilTvYHZ19okSbPHT/Td7qiwWLoply5AQAAAAAAAAA=", "node": { "consistentStateForEachCoin": { "owner": { @@ -666,37 +666,37 @@ Response: { "coins": { "edges": [ { - "cursor": "ICiav5I6Mkx08X0VmoZKIJ0awF2KpVcGFefQ4GWueq9jAQAAAAAAAAA=", + "cursor": "INF4y6RgI+x6+uilTvYHZ19okSbPHT/Td7qiwWLoply5AQAAAAAAAAA=", "node": { "contents": { "json": { - "id": "0x289abf923a324c74f17d159a864a209d1ac05d8aa5570615e7d0e065ae7aaf63", + "id": "0xd178cba46023ec7afae8a54ef607675f689126cf1d3fd377baa2c162e8a65cb9", "balance": { - "value": "100" + "value": "200" } } } } }, { - "cursor": "IKQYR4gBIlqmEkXHMhZsUUbfKoX8aufbPgILwCO/Sly9AQAAAAAAAAA=", + "cursor": "IOfJiINYZ0h4ktDswip1pPKO10xxW2+MxPXoCXaG0jjHAQAAAAAAAAA=", "node": { "contents": { "json": { - "id": "0xa418478801225aa61245c732166c5146df2a85fc6ae7db3e020bc023bf4a5cbd", + "id": "0xe7c988835867487892d0ecc22a75a4f28ed74c715b6f8cc4f5e8097686d238c7", "balance": { - "value": "200" + "value": "100" } } } } }, { - "cursor": "IOtyLmahCDl5xXyOjB0WMqX9cUF4/ZkicypBnpx9OxxlAQAAAAAAAAA=", + "cursor": "IPj4cRR2GNmdRMDkAa374gC9VjY1lCd4DFcmTQZIYn+eAQAAAAAAAAA=", "node": { "contents": { "json": { - "id": "0xeb722e66a1083979c57c8e8c1d1632a5fd714178fd9922732a419e9c7d3b1c65", + "id": "0xf8f871147618d99d44c0e401adfbe200bd5636359427780c57264d0648627f9e", "balance": { "value": "300" } @@ -710,16 +710,16 @@ Response: { }, "contents": { "json": { - "id": "0x289abf923a324c74f17d159a864a209d1ac05d8aa5570615e7d0e065ae7aaf63", + "id": "0xd178cba46023ec7afae8a54ef607675f689126cf1d3fd377baa2c162e8a65cb9", "balance": { - "value": "100" + "value": "200" } } } } }, { - "cursor": "IKQYR4gBIlqmEkXHMhZsUUbfKoX8aufbPgILwCO/Sly9AQAAAAAAAAA=", + "cursor": "IOfJiINYZ0h4ktDswip1pPKO10xxW2+MxPXoCXaG0jjHAQAAAAAAAAA=", "node": { "consistentStateForEachCoin": { "owner": { @@ -727,37 +727,37 @@ Response: { "coins": { "edges": [ { - "cursor": "ICiav5I6Mkx08X0VmoZKIJ0awF2KpVcGFefQ4GWueq9jAQAAAAAAAAA=", + "cursor": "INF4y6RgI+x6+uilTvYHZ19okSbPHT/Td7qiwWLoply5AQAAAAAAAAA=", "node": { "contents": { "json": { - "id": "0x289abf923a324c74f17d159a864a209d1ac05d8aa5570615e7d0e065ae7aaf63", + "id": "0xd178cba46023ec7afae8a54ef607675f689126cf1d3fd377baa2c162e8a65cb9", "balance": { - "value": "100" + "value": "200" } } } } }, { - "cursor": "IKQYR4gBIlqmEkXHMhZsUUbfKoX8aufbPgILwCO/Sly9AQAAAAAAAAA=", + "cursor": "IOfJiINYZ0h4ktDswip1pPKO10xxW2+MxPXoCXaG0jjHAQAAAAAAAAA=", "node": { "contents": { "json": { - "id": "0xa418478801225aa61245c732166c5146df2a85fc6ae7db3e020bc023bf4a5cbd", + "id": "0xe7c988835867487892d0ecc22a75a4f28ed74c715b6f8cc4f5e8097686d238c7", "balance": { - "value": "200" + "value": "100" } } } } }, { - "cursor": "IOtyLmahCDl5xXyOjB0WMqX9cUF4/ZkicypBnpx9OxxlAQAAAAAAAAA=", + "cursor": "IPj4cRR2GNmdRMDkAa374gC9VjY1lCd4DFcmTQZIYn+eAQAAAAAAAAA=", "node": { "contents": { "json": { - "id": "0xeb722e66a1083979c57c8e8c1d1632a5fd714178fd9922732a419e9c7d3b1c65", + "id": "0xf8f871147618d99d44c0e401adfbe200bd5636359427780c57264d0648627f9e", "balance": { "value": "300" } @@ -771,9 +771,9 @@ Response: { }, "contents": { "json": { - "id": "0xa418478801225aa61245c732166c5146df2a85fc6ae7db3e020bc023bf4a5cbd", + "id": "0xe7c988835867487892d0ecc22a75a4f28ed74c715b6f8cc4f5e8097686d238c7", "balance": { - "value": "200" + "value": "100" } } } @@ -785,26 +785,26 @@ Response: { "coins": { "edges": [ { - "cursor": "ICiav5I6Mkx08X0VmoZKIJ0awF2KpVcGFefQ4GWueq9jAQAAAAAAAAA=", + "cursor": "INF4y6RgI+x6+uilTvYHZ19okSbPHT/Td7qiwWLoply5AQAAAAAAAAA=", "node": { "contents": { "json": { - "id": "0x289abf923a324c74f17d159a864a209d1ac05d8aa5570615e7d0e065ae7aaf63", + "id": "0xd178cba46023ec7afae8a54ef607675f689126cf1d3fd377baa2c162e8a65cb9", "balance": { - "value": "100" + "value": "200" } } } } }, { - "cursor": "IKQYR4gBIlqmEkXHMhZsUUbfKoX8aufbPgILwCO/Sly9AQAAAAAAAAA=", + "cursor": "IOfJiINYZ0h4ktDswip1pPKO10xxW2+MxPXoCXaG0jjHAQAAAAAAAAA=", "node": { "contents": { "json": { - "id": "0xa418478801225aa61245c732166c5146df2a85fc6ae7db3e020bc023bf4a5cbd", + "id": "0xe7c988835867487892d0ecc22a75a4f28ed74c715b6f8cc4f5e8097686d238c7", "balance": { - "value": "200" + "value": "100" } } } diff --git a/crates/iota-graphql-e2e-tests/tests/consistency/dynamic_fields/deleted_df.exp b/crates/iota-graphql-e2e-tests/tests/consistency/dynamic_fields/deleted_df.exp index 8f2b41dd9d8..59f391792b2 100644 --- a/crates/iota-graphql-e2e-tests/tests/consistency/dynamic_fields/deleted_df.exp +++ b/crates/iota-graphql-e2e-tests/tests/consistency/dynamic_fields/deleted_df.exp @@ -90,29 +90,29 @@ Response: { "dynamicFields": { "edges": [ { - "cursor": "ILE7Qmd7Si0bo8DRAwOOkkUjscgq8eMVSXbKUzme5ggeAQAAAAAAAAA=", + "cursor": "IFeBXm4vjap9M5dVNXzXVaTHhuhTRg2+xYogFuZZLxPuAQAAAAAAAAA=", "node": { "name": { - "bcs": "A2RmNA==" + "bcs": "A2RmNQ==" }, "value": { - "json": "df4" + "json": "df5" } } }, { - "cursor": "IMHYTm10WoA1BA2R7UWStxDRk7fLxO3XggS9/gg+DuYyAQAAAAAAAAA=", + "cursor": "IH8ALtE7vSZE3UtPP9JRPluBoy8YqFRWE3q+E/oWrlCkAQAAAAAAAAA=", "node": { "name": { - "bcs": "A2RmNQ==" + "bcs": "A2RmNA==" }, "value": { - "json": "df5" + "json": "df4" } } }, { - "cursor": "IMJls0MmMIcWpo4E20v0gGl+nU2SuOa7XQC7CUalmNBAAQAAAAAAAAA=", + "cursor": "II67/lXdHT9zp83rSD1Zh3kBQnXOJcQpHN4ARyucBl77AQAAAAAAAAA=", "node": { "name": { "bcs": "A2RmNg==" @@ -139,29 +139,29 @@ Response: { "dynamicFields": { "edges": [ { - "cursor": "ILE7Qmd7Si0bo8DRAwOOkkUjscgq8eMVSXbKUzme5ggeAQAAAAAAAAA=", + "cursor": "IFeBXm4vjap9M5dVNXzXVaTHhuhTRg2+xYogFuZZLxPuAQAAAAAAAAA=", "node": { "name": { - "bcs": "A2RmNA==" + "bcs": "A2RmNQ==" }, "value": { - "json": "df4" + "json": "df5" } } }, { - "cursor": "IMHYTm10WoA1BA2R7UWStxDRk7fLxO3XggS9/gg+DuYyAQAAAAAAAAA=", + "cursor": "IH8ALtE7vSZE3UtPP9JRPluBoy8YqFRWE3q+E/oWrlCkAQAAAAAAAAA=", "node": { "name": { - "bcs": "A2RmNQ==" + "bcs": "A2RmNA==" }, "value": { - "json": "df5" + "json": "df4" } } }, { - "cursor": "IMJls0MmMIcWpo4E20v0gGl+nU2SuOa7XQC7CUalmNBAAQAAAAAAAAA=", + "cursor": "II67/lXdHT9zp83rSD1Zh3kBQnXOJcQpHN4ARyucBl77AQAAAAAAAAA=", "node": { "name": { "bcs": "A2RmNg==" @@ -188,68 +188,68 @@ Response: { "dynamicFields": { "edges": [ { - "cursor": "IBo1+VVeBsyCYwlrL1rN5BnZ7NRXWHrkSr/9qc3pWXB9AQAAAAAAAAA=", + "cursor": "IBXEM7sfiif6smxgIJmBWkxMn6US7z34TC/rW+NOXQmaAQAAAAAAAAA=", "node": { "name": { - "bcs": "A2RmMQ==" + "bcs": "A2RmMg==" }, "value": { - "json": "df1" + "json": "df2" } } }, { - "cursor": "IGcVjRUu7AcPIf24HKtfNKvbs8lG09f8hVDphXh1jGCBAQAAAAAAAAA=", + "cursor": "IFeBXm4vjap9M5dVNXzXVaTHhuhTRg2+xYogFuZZLxPuAQAAAAAAAAA=", "node": { "name": { - "bcs": "A2RmMw==" + "bcs": "A2RmNQ==" }, "value": { - "json": "df3" + "json": "df5" } } }, { - "cursor": "IItF7aouV9DuiVuj+BMc52TG4SkgwY62esLSW5q6c8fWAQAAAAAAAAA=", + "cursor": "IH8ALtE7vSZE3UtPP9JRPluBoy8YqFRWE3q+E/oWrlCkAQAAAAAAAAA=", "node": { "name": { - "bcs": "A2RmMg==" + "bcs": "A2RmNA==" }, "value": { - "json": "df2" + "json": "df4" } } }, { - "cursor": "ILE7Qmd7Si0bo8DRAwOOkkUjscgq8eMVSXbKUzme5ggeAQAAAAAAAAA=", + "cursor": "IIKVY5ECiDNemkTq/lVCwzDt44fZpeAIK+iQ+EcwQygTAQAAAAAAAAA=", "node": { "name": { - "bcs": "A2RmNA==" + "bcs": "A2RmMw==" }, "value": { - "json": "df4" + "json": "df3" } } }, { - "cursor": "IMHYTm10WoA1BA2R7UWStxDRk7fLxO3XggS9/gg+DuYyAQAAAAAAAAA=", + "cursor": "II67/lXdHT9zp83rSD1Zh3kBQnXOJcQpHN4ARyucBl77AQAAAAAAAAA=", "node": { "name": { - "bcs": "A2RmNQ==" + "bcs": "A2RmNg==" }, "value": { - "json": "df5" + "json": "df6" } } }, { - "cursor": "IMJls0MmMIcWpo4E20v0gGl+nU2SuOa7XQC7CUalmNBAAQAAAAAAAAA=", + "cursor": "INUppr40jINpPev9/A4UIbKtREBWW8h1nMw6NQk1U8xnAQAAAAAAAAA=", "node": { "name": { - "bcs": "A2RmNg==" + "bcs": "A2RmMQ==" }, "value": { - "json": "df6" + "json": "df1" } } } @@ -283,29 +283,29 @@ Response: { "dynamicFields": { "edges": [ { - "cursor": "ILE7Qmd7Si0bo8DRAwOOkkUjscgq8eMVSXbKUzme5ggeAQAAAAAAAAA=", + "cursor": "IFeBXm4vjap9M5dVNXzXVaTHhuhTRg2+xYogFuZZLxPuAQAAAAAAAAA=", "node": { "name": { - "bcs": "A2RmNA==" + "bcs": "A2RmNQ==" }, "value": { - "json": "df4" + "json": "df5" } } }, { - "cursor": "IMHYTm10WoA1BA2R7UWStxDRk7fLxO3XggS9/gg+DuYyAQAAAAAAAAA=", + "cursor": "IH8ALtE7vSZE3UtPP9JRPluBoy8YqFRWE3q+E/oWrlCkAQAAAAAAAAA=", "node": { "name": { - "bcs": "A2RmNQ==" + "bcs": "A2RmNA==" }, "value": { - "json": "df5" + "json": "df4" } } }, { - "cursor": "IMJls0MmMIcWpo4E20v0gGl+nU2SuOa7XQC7CUalmNBAAQAAAAAAAAA=", + "cursor": "II67/lXdHT9zp83rSD1Zh3kBQnXOJcQpHN4ARyucBl77AQAAAAAAAAA=", "node": { "name": { "bcs": "A2RmNg==" diff --git a/crates/iota-graphql-e2e-tests/tests/consistency/dynamic_fields/deleted_dof.exp b/crates/iota-graphql-e2e-tests/tests/consistency/dynamic_fields/deleted_dof.exp index dd9eaa4fe1a..522210a7f7b 100644 --- a/crates/iota-graphql-e2e-tests/tests/consistency/dynamic_fields/deleted_dof.exp +++ b/crates/iota-graphql-e2e-tests/tests/consistency/dynamic_fields/deleted_dof.exp @@ -41,7 +41,7 @@ Response: { "dynamicFields": { "edges": [ { - "cursor": "IOYgMJlQDDjMXCaBVDpLjGXJTNsBdDTHqO6C5QElBkZ8AQAAAAAAAAA=", + "cursor": "IHwP9laGJmLOj7bHnxSoHMm/rKzHL1L8QMdX0Ybot758AQAAAAAAAAA=", "node": { "name": { "bcs": "KgAAAAAAAAA=" @@ -49,7 +49,7 @@ Response: { "value": { "contents": { "json": { - "id": "0x8ea9cbcf863a9cd6cc23a403d7de8eca3e72289bae85a75efa7cb1fe8d0bf5cd", + "id": "0x43b69600797ba3a965c53835303ba49f52dfc23dc93a634cd2954a50a45fd223", "count": "0" } } @@ -65,7 +65,7 @@ Response: { "value": { "contents": { "json": { - "id": "0x8ea9cbcf863a9cd6cc23a403d7de8eca3e72289bae85a75efa7cb1fe8d0bf5cd", + "id": "0x43b69600797ba3a965c53835303ba49f52dfc23dc93a634cd2954a50a45fd223", "count": "0" } } @@ -77,7 +77,7 @@ Response: { "dynamicFields": { "edges": [ { - "cursor": "IOYgMJlQDDjMXCaBVDpLjGXJTNsBdDTHqO6C5QElBkZ8AQAAAAAAAAA=", + "cursor": "IHwP9laGJmLOj7bHnxSoHMm/rKzHL1L8QMdX0Ybot758AQAAAAAAAAA=", "node": { "name": { "bcs": "KgAAAAAAAAA=" @@ -85,7 +85,7 @@ Response: { "value": { "contents": { "json": { - "id": "0x8ea9cbcf863a9cd6cc23a403d7de8eca3e72289bae85a75efa7cb1fe8d0bf5cd", + "id": "0x43b69600797ba3a965c53835303ba49f52dfc23dc93a634cd2954a50a45fd223", "count": "0" } } @@ -101,7 +101,7 @@ Response: { "value": { "contents": { "json": { - "id": "0x8ea9cbcf863a9cd6cc23a403d7de8eca3e72289bae85a75efa7cb1fe8d0bf5cd", + "id": "0x43b69600797ba3a965c53835303ba49f52dfc23dc93a634cd2954a50a45fd223", "count": "0" } } @@ -117,7 +117,7 @@ Response: { "value": { "contents": { "json": { - "id": "0x8ea9cbcf863a9cd6cc23a403d7de8eca3e72289bae85a75efa7cb1fe8d0bf5cd", + "id": "0x43b69600797ba3a965c53835303ba49f52dfc23dc93a634cd2954a50a45fd223", "count": "0" } } @@ -168,7 +168,7 @@ Response: { "value": { "contents": { "json": { - "id": "0x8ea9cbcf863a9cd6cc23a403d7de8eca3e72289bae85a75efa7cb1fe8d0bf5cd", + "id": "0x43b69600797ba3a965c53835303ba49f52dfc23dc93a634cd2954a50a45fd223", "count": "0" } } @@ -222,7 +222,7 @@ Response: { "value": { "contents": { "json": { - "id": "0x8ea9cbcf863a9cd6cc23a403d7de8eca3e72289bae85a75efa7cb1fe8d0bf5cd", + "id": "0x43b69600797ba3a965c53835303ba49f52dfc23dc93a634cd2954a50a45fd223", "count": "0" } } diff --git a/crates/iota-graphql-e2e-tests/tests/consistency/dynamic_fields/dof_add_reclaim_transfer.exp b/crates/iota-graphql-e2e-tests/tests/consistency/dynamic_fields/dof_add_reclaim_transfer.exp index 49ec6c8ff7f..1132de246a4 100644 --- a/crates/iota-graphql-e2e-tests/tests/consistency/dynamic_fields/dof_add_reclaim_transfer.exp +++ b/crates/iota-graphql-e2e-tests/tests/consistency/dynamic_fields/dof_add_reclaim_transfer.exp @@ -36,7 +36,7 @@ Response: { "dynamicFields": { "edges": [ { - "cursor": "IEpbq/BIsDWp1KcUACgk+IAa4fDSSNBFUCIuxhKoAf3SAQAAAAAAAAA=", + "cursor": "IHXw7HKd1+5wVviB/aZV3hOHElzvVHueTKMKQQ7bL6+bAQAAAAAAAAA=", "node": { "name": { "bcs": "KgAAAAAAAAA=" @@ -44,7 +44,7 @@ Response: { "value": { "contents": { "json": { - "id": "0x9afdb581d3012f103c984391f1aa9e6c7bfe996cf8a4736a2f55eea644c3ad8a", + "id": "0x59ec032f03280718a543022037bfc541b929e2163fb01bfb3375e91e07dd46b9", "count": "0" } } @@ -60,7 +60,7 @@ Response: { "value": { "contents": { "json": { - "id": "0x9afdb581d3012f103c984391f1aa9e6c7bfe996cf8a4736a2f55eea644c3ad8a", + "id": "0x59ec032f03280718a543022037bfc541b929e2163fb01bfb3375e91e07dd46b9", "count": "0" } } @@ -71,7 +71,7 @@ Response: { "dynamicFields": { "edges": [ { - "cursor": "IEpbq/BIsDWp1KcUACgk+IAa4fDSSNBFUCIuxhKoAf3SAQAAAAAAAAA=", + "cursor": "IHXw7HKd1+5wVviB/aZV3hOHElzvVHueTKMKQQ7bL6+bAQAAAAAAAAA=", "node": { "name": { "bcs": "KgAAAAAAAAA=" @@ -79,7 +79,7 @@ Response: { "value": { "contents": { "json": { - "id": "0x9afdb581d3012f103c984391f1aa9e6c7bfe996cf8a4736a2f55eea644c3ad8a", + "id": "0x59ec032f03280718a543022037bfc541b929e2163fb01bfb3375e91e07dd46b9", "count": "0" } } @@ -95,7 +95,7 @@ Response: { "value": { "contents": { "json": { - "id": "0x9afdb581d3012f103c984391f1aa9e6c7bfe996cf8a4736a2f55eea644c3ad8a", + "id": "0x59ec032f03280718a543022037bfc541b929e2163fb01bfb3375e91e07dd46b9", "count": "0" } } @@ -107,7 +107,7 @@ Response: { "dynamicFields": { "edges": [ { - "cursor": "IEpbq/BIsDWp1KcUACgk+IAa4fDSSNBFUCIuxhKoAf3SAQAAAAAAAAA=", + "cursor": "IHXw7HKd1+5wVviB/aZV3hOHElzvVHueTKMKQQ7bL6+bAQAAAAAAAAA=", "node": { "name": { "bcs": "KgAAAAAAAAA=" @@ -115,7 +115,7 @@ Response: { "value": { "contents": { "json": { - "id": "0x9afdb581d3012f103c984391f1aa9e6c7bfe996cf8a4736a2f55eea644c3ad8a", + "id": "0x59ec032f03280718a543022037bfc541b929e2163fb01bfb3375e91e07dd46b9", "count": "0" } } @@ -131,7 +131,7 @@ Response: { "value": { "contents": { "json": { - "id": "0x9afdb581d3012f103c984391f1aa9e6c7bfe996cf8a4736a2f55eea644c3ad8a", + "id": "0x59ec032f03280718a543022037bfc541b929e2163fb01bfb3375e91e07dd46b9", "count": "0" } } @@ -184,7 +184,7 @@ Response: { "value": { "contents": { "json": { - "id": "0x9afdb581d3012f103c984391f1aa9e6c7bfe996cf8a4736a2f55eea644c3ad8a", + "id": "0x59ec032f03280718a543022037bfc541b929e2163fb01bfb3375e91e07dd46b9", "count": "0" } } diff --git a/crates/iota-graphql-e2e-tests/tests/consistency/dynamic_fields/dof_add_reclaim_transfer_reclaim_add.exp b/crates/iota-graphql-e2e-tests/tests/consistency/dynamic_fields/dof_add_reclaim_transfer_reclaim_add.exp index 1615ab1847f..ba1d2bc19e7 100644 --- a/crates/iota-graphql-e2e-tests/tests/consistency/dynamic_fields/dof_add_reclaim_transfer_reclaim_add.exp +++ b/crates/iota-graphql-e2e-tests/tests/consistency/dynamic_fields/dof_add_reclaim_transfer_reclaim_add.exp @@ -61,7 +61,7 @@ Response: { "dynamicFields": { "edges": [ { - "cursor": "IGwYH5v+7AWkcui2XgICiCBJE0IV0cDJpSvHs1P/j6uOAQAAAAAAAAA=", + "cursor": "IFqAyNNcnwwa40SuWqyr9JjpRb1PDilkP9QiOeS0oCqcAQAAAAAAAAA=", "node": { "name": { "bcs": "KgAAAAAAAAA=" @@ -69,7 +69,7 @@ Response: { "value": { "contents": { "json": { - "id": "0xceba7e0eb5c3dcfa4567dc4c3b19ef8c030e769cfce310fa6178a65bb3938d2e", + "id": "0x3093e81d81c56c6e05a9edd08d214d88d955cf22c93fc61fd8798486763f25c9", "count": "0" } } @@ -85,7 +85,7 @@ Response: { "value": { "contents": { "json": { - "id": "0xceba7e0eb5c3dcfa4567dc4c3b19ef8c030e769cfce310fa6178a65bb3938d2e", + "id": "0x3093e81d81c56c6e05a9edd08d214d88d955cf22c93fc61fd8798486763f25c9", "count": "0" } } @@ -96,7 +96,7 @@ Response: { "dynamicFields": { "edges": [ { - "cursor": "IGwYH5v+7AWkcui2XgICiCBJE0IV0cDJpSvHs1P/j6uOAQAAAAAAAAA=", + "cursor": "IFqAyNNcnwwa40SuWqyr9JjpRb1PDilkP9QiOeS0oCqcAQAAAAAAAAA=", "node": { "name": { "bcs": "KgAAAAAAAAA=" @@ -104,7 +104,7 @@ Response: { "value": { "contents": { "json": { - "id": "0xceba7e0eb5c3dcfa4567dc4c3b19ef8c030e769cfce310fa6178a65bb3938d2e", + "id": "0x3093e81d81c56c6e05a9edd08d214d88d955cf22c93fc61fd8798486763f25c9", "count": "0" } } @@ -120,7 +120,7 @@ Response: { "value": { "contents": { "json": { - "id": "0xceba7e0eb5c3dcfa4567dc4c3b19ef8c030e769cfce310fa6178a65bb3938d2e", + "id": "0x3093e81d81c56c6e05a9edd08d214d88d955cf22c93fc61fd8798486763f25c9", "count": "0" } } @@ -139,7 +139,7 @@ Response: { "dynamicFields": { "edges": [ { - "cursor": "IGwYH5v+7AWkcui2XgICiCBJE0IV0cDJpSvHs1P/j6uOAQAAAAAAAAA=", + "cursor": "IFqAyNNcnwwa40SuWqyr9JjpRb1PDilkP9QiOeS0oCqcAQAAAAAAAAA=", "node": { "name": { "bcs": "KgAAAAAAAAA=" @@ -147,7 +147,7 @@ Response: { "value": { "contents": { "json": { - "id": "0xceba7e0eb5c3dcfa4567dc4c3b19ef8c030e769cfce310fa6178a65bb3938d2e", + "id": "0x3093e81d81c56c6e05a9edd08d214d88d955cf22c93fc61fd8798486763f25c9", "count": "0" } } @@ -163,7 +163,7 @@ Response: { "value": { "contents": { "json": { - "id": "0xceba7e0eb5c3dcfa4567dc4c3b19ef8c030e769cfce310fa6178a65bb3938d2e", + "id": "0x3093e81d81c56c6e05a9edd08d214d88d955cf22c93fc61fd8798486763f25c9", "count": "0" } } @@ -182,7 +182,7 @@ Response: { "dynamicFields": { "edges": [ { - "cursor": "IGwYH5v+7AWkcui2XgICiCBJE0IV0cDJpSvHs1P/j6uOAQAAAAAAAAA=", + "cursor": "IFqAyNNcnwwa40SuWqyr9JjpRb1PDilkP9QiOeS0oCqcAQAAAAAAAAA=", "node": { "name": { "bcs": "KgAAAAAAAAA=" @@ -190,7 +190,7 @@ Response: { "value": { "contents": { "json": { - "id": "0xceba7e0eb5c3dcfa4567dc4c3b19ef8c030e769cfce310fa6178a65bb3938d2e", + "id": "0x3093e81d81c56c6e05a9edd08d214d88d955cf22c93fc61fd8798486763f25c9", "count": "0" } } @@ -206,7 +206,7 @@ Response: { "value": { "contents": { "json": { - "id": "0xceba7e0eb5c3dcfa4567dc4c3b19ef8c030e769cfce310fa6178a65bb3938d2e", + "id": "0x3093e81d81c56c6e05a9edd08d214d88d955cf22c93fc61fd8798486763f25c9", "count": "0" } } diff --git a/crates/iota-graphql-e2e-tests/tests/consistency/dynamic_fields/dynamic_fields.exp b/crates/iota-graphql-e2e-tests/tests/consistency/dynamic_fields/dynamic_fields.exp index 1fb575585d2..fdcd9547df5 100644 --- a/crates/iota-graphql-e2e-tests/tests/consistency/dynamic_fields/dynamic_fields.exp +++ b/crates/iota-graphql-e2e-tests/tests/consistency/dynamic_fields/dynamic_fields.exp @@ -84,7 +84,7 @@ task 9, lines 103-165: Response: { "data": { "parent_version_2_no_dof": { - "address": "0xe81d1d628bb5942e563dc3ca652f41dfbe6a7ad11ca866249bafe4e29609f077", + "address": "0x01b231aeb199e96f501fb02e027a6436108904302fd085ccdddf78eb880149d0", "dynamicFields": { "edges": [] } @@ -93,7 +93,7 @@ Response: { "dynamicFields": { "edges": [ { - "cursor": "IBkflpr//S+rLcwsf9BrQULoOCUdF2gzhpDlWnLv9dvJAQAAAAAAAAA=", + "cursor": "IFMDN2LB7x4O3i2h+Fjvd5EOi9hYGWmuy0woaBOI9ieiAQAAAAAAAAA=", "node": { "name": { "bcs": "pAEAAAAAAAA=", @@ -104,7 +104,7 @@ Response: { "value": { "contents": { "json": { - "id": "0x8e27ff5a173340bddbd8bcf1483a31f4dba5e4387006bf283a9cfdfffebefb60", + "id": "0x3afad17106d68ef22cc302d2bcf243767b6d23c4b0455bab226cf42dab534a6b", "count": "1" } } @@ -115,13 +115,13 @@ Response: { } }, "child_version_2_no_parent": { - "address": "0x8e27ff5a173340bddbd8bcf1483a31f4dba5e4387006bf283a9cfdfffebefb60", + "address": "0x3afad17106d68ef22cc302d2bcf243767b6d23c4b0455bab226cf42dab534a6b", "owner": {} }, "child_version_3_has_parent": { "owner": { "parent": { - "address": "0x191f969afffd2fab2dcc2c7fd06b4142e838251d1768338690e55a72eff5dbc9" + "address": "0x53033762c1ef1e0ede2da1f858ef77910e8bd8581969aecb4c28681388f627a2" } } } @@ -173,63 +173,63 @@ Response: { "dynamicFields": { "edges": [ { - "cursor": "IALh6Gmj1i0tlaFppLIbcxwvTEoesuYprwx6kb++hQptAgAAAAAAAAA=", + "cursor": "IClawurZkDgT+lOfghnjBHn+PLUx66DXjrgRHFWlMokIAgAAAAAAAAA=", "node": { "name": { - "bcs": "A2RmMw==", + "bcs": "A2RmMQ==", "type": { "repr": "0x0000000000000000000000000000000000000000000000000000000000000001::string::String" } }, "value": { - "json": "df3" + "json": "df1" } } }, { - "cursor": "IBkflpr//S+rLcwsf9BrQULoOCUdF2gzhpDlWnLv9dvJAgAAAAAAAAA=", + "cursor": "IEka7584A4U5vrD9MH0Sfiqot3d9S1fFF1xTWGGMOaEkAgAAAAAAAAA=", "node": { "name": { - "bcs": "pAEAAAAAAAA=", + "bcs": "A2RmMg==", "type": { - "repr": "u64" + "repr": "0x0000000000000000000000000000000000000000000000000000000000000001::string::String" } }, "value": { - "contents": { - "json": { - "id": "0x8e27ff5a173340bddbd8bcf1483a31f4dba5e4387006bf283a9cfdfffebefb60", - "count": "2" - } - } + "json": "df2" } } }, { - "cursor": "IDoFKasvO3uRG36i8kDIIFwQcloILQn2wF4PAQIcTwYqAgAAAAAAAAA=", + "cursor": "IFMDN2LB7x4O3i2h+Fjvd5EOi9hYGWmuy0woaBOI9ieiAgAAAAAAAAA=", "node": { "name": { - "bcs": "A2RmMg==", + "bcs": "pAEAAAAAAAA=", "type": { - "repr": "0x0000000000000000000000000000000000000000000000000000000000000001::string::String" + "repr": "u64" } }, "value": { - "json": "df2" + "contents": { + "json": { + "id": "0x3afad17106d68ef22cc302d2bcf243767b6d23c4b0455bab226cf42dab534a6b", + "count": "2" + } + } } } }, { - "cursor": "ILZJDhqQtyqtQ07tnHozoq0BbJmXlZQypzZ+hHp3ZIBiAgAAAAAAAAA=", + "cursor": "INdxBwgkvilBjMxtXP7iG+Ca5Fbl3XI1QmiAEWPxneVGAgAAAAAAAAA=", "node": { "name": { - "bcs": "A2RmMQ==", + "bcs": "A2RmMw==", "type": { "repr": "0x0000000000000000000000000000000000000000000000000000000000000001::string::String" } }, "value": { - "json": "df1" + "json": "df3" } } } @@ -240,7 +240,7 @@ Response: { "dynamicFields": { "edges": [ { - "cursor": "IBkflpr//S+rLcwsf9BrQULoOCUdF2gzhpDlWnLv9dvJAgAAAAAAAAA=", + "cursor": "IFMDN2LB7x4O3i2h+Fjvd5EOi9hYGWmuy0woaBOI9ieiAgAAAAAAAAA=", "node": { "name": { "bcs": "pAEAAAAAAAA=", @@ -251,7 +251,7 @@ Response: { "value": { "contents": { "json": { - "id": "0x8e27ff5a173340bddbd8bcf1483a31f4dba5e4387006bf283a9cfdfffebefb60", + "id": "0x3afad17106d68ef22cc302d2bcf243767b6d23c4b0455bab226cf42dab534a6b", "count": "1" } } @@ -270,30 +270,16 @@ Response: { "dynamicFields": { "edges": [ { - "cursor": "IDoFKasvO3uRG36i8kDIIFwQcloILQn2wF4PAQIcTwYqAgAAAAAAAAA=", + "cursor": "INdxBwgkvilBjMxtXP7iG+Ca5Fbl3XI1QmiAEWPxneVGAgAAAAAAAAA=", "node": { "name": { - "bcs": "A2RmMg==", - "type": { - "repr": "0x0000000000000000000000000000000000000000000000000000000000000001::string::String" - } - }, - "value": { - "json": "df2" - } - } - }, - { - "cursor": "ILZJDhqQtyqtQ07tnHozoq0BbJmXlZQypzZ+hHp3ZIBiAgAAAAAAAAA=", - "node": { - "name": { - "bcs": "A2RmMQ==", + "bcs": "A2RmMw==", "type": { "repr": "0x0000000000000000000000000000000000000000000000000000000000000001::string::String" } }, "value": { - "json": "df1" + "json": "df3" } } } @@ -328,7 +314,7 @@ Response: { "value": { "contents": { "json": { - "id": "0x8e27ff5a173340bddbd8bcf1483a31f4dba5e4387006bf283a9cfdfffebefb60", + "id": "0x3afad17106d68ef22cc302d2bcf243767b6d23c4b0455bab226cf42dab534a6b", "count": "1" } } @@ -347,7 +333,7 @@ Response: { "value": { "contents": { "json": { - "id": "0x8e27ff5a173340bddbd8bcf1483a31f4dba5e4387006bf283a9cfdfffebefb60", + "id": "0x3afad17106d68ef22cc302d2bcf243767b6d23c4b0455bab226cf42dab534a6b", "count": "2" } } @@ -412,63 +398,63 @@ Response: { "dynamicFields": { "edges": [ { - "cursor": "IALh6Gmj1i0tlaFppLIbcxwvTEoesuYprwx6kb++hQptAwAAAAAAAAA=", + "cursor": "IClawurZkDgT+lOfghnjBHn+PLUx66DXjrgRHFWlMokIAwAAAAAAAAA=", "node": { "name": { - "bcs": "A2RmMw==", + "bcs": "A2RmMQ==", "type": { "repr": "0x0000000000000000000000000000000000000000000000000000000000000001::string::String" } }, "value": { - "json": "df3" + "json": "df1" } } }, { - "cursor": "IBkflpr//S+rLcwsf9BrQULoOCUdF2gzhpDlWnLv9dvJAwAAAAAAAAA=", + "cursor": "IEka7584A4U5vrD9MH0Sfiqot3d9S1fFF1xTWGGMOaEkAwAAAAAAAAA=", "node": { "name": { - "bcs": "pAEAAAAAAAA=", + "bcs": "A2RmMg==", "type": { - "repr": "u64" + "repr": "0x0000000000000000000000000000000000000000000000000000000000000001::string::String" } }, "value": { - "contents": { - "json": { - "id": "0x8e27ff5a173340bddbd8bcf1483a31f4dba5e4387006bf283a9cfdfffebefb60", - "count": "2" - } - } + "json": "df2" } } }, { - "cursor": "IDoFKasvO3uRG36i8kDIIFwQcloILQn2wF4PAQIcTwYqAwAAAAAAAAA=", + "cursor": "IFMDN2LB7x4O3i2h+Fjvd5EOi9hYGWmuy0woaBOI9ieiAwAAAAAAAAA=", "node": { "name": { - "bcs": "A2RmMg==", + "bcs": "pAEAAAAAAAA=", "type": { - "repr": "0x0000000000000000000000000000000000000000000000000000000000000001::string::String" + "repr": "u64" } }, "value": { - "json": "df2" + "contents": { + "json": { + "id": "0x3afad17106d68ef22cc302d2bcf243767b6d23c4b0455bab226cf42dab534a6b", + "count": "2" + } + } } } }, { - "cursor": "ILZJDhqQtyqtQ07tnHozoq0BbJmXlZQypzZ+hHp3ZIBiAwAAAAAAAAA=", + "cursor": "INdxBwgkvilBjMxtXP7iG+Ca5Fbl3XI1QmiAEWPxneVGAwAAAAAAAAA=", "node": { "name": { - "bcs": "A2RmMQ==", + "bcs": "A2RmMw==", "type": { "repr": "0x0000000000000000000000000000000000000000000000000000000000000001::string::String" } }, "value": { - "json": "df1" + "json": "df3" } } } @@ -479,21 +465,27 @@ Response: { "dynamicFields": { "edges": [ { - "cursor": "IDoFKasvO3uRG36i8kDIIFwQcloILQn2wF4PAQIcTwYqAgAAAAAAAAA=", + "cursor": "INdxBwgkvilBjMxtXP7iG+Ca5Fbl3XI1QmiAEWPxneVGAgAAAAAAAAA=", "node": { "name": { - "bcs": "A2RmMg==", + "bcs": "A2RmMw==", "type": { "repr": "0x0000000000000000000000000000000000000000000000000000000000000001::string::String" } }, "value": { - "json": "df2" + "json": "df3" } } - }, + } + ] + } + }, + "parent_version_5_has_7_children": { + "dynamicFields": { + "edges": [ { - "cursor": "ILZJDhqQtyqtQ07tnHozoq0BbJmXlZQypzZ+hHp3ZIBiAgAAAAAAAAA=", + "cursor": "IClawurZkDgT+lOfghnjBHn+PLUx66DXjrgRHFWlMokIAwAAAAAAAAA=", "node": { "name": { "bcs": "A2RmMQ==", @@ -505,29 +497,23 @@ Response: { "json": "df1" } } - } - ] - } - }, - "parent_version_5_has_7_children": { - "dynamicFields": { - "edges": [ + }, { - "cursor": "IALh6Gmj1i0tlaFppLIbcxwvTEoesuYprwx6kb++hQptAwAAAAAAAAA=", + "cursor": "IEka7584A4U5vrD9MH0Sfiqot3d9S1fFF1xTWGGMOaEkAwAAAAAAAAA=", "node": { "name": { - "bcs": "A2RmMw==", + "bcs": "A2RmMg==", "type": { "repr": "0x0000000000000000000000000000000000000000000000000000000000000001::string::String" } }, "value": { - "json": "df3" + "json": "df2" } } }, { - "cursor": "IBkflpr//S+rLcwsf9BrQULoOCUdF2gzhpDlWnLv9dvJAwAAAAAAAAA=", + "cursor": "IFMDN2LB7x4O3i2h+Fjvd5EOi9hYGWmuy0woaBOI9ieiAwAAAAAAAAA=", "node": { "name": { "bcs": "pAEAAAAAAAA=", @@ -538,7 +524,7 @@ Response: { "value": { "contents": { "json": { - "id": "0x8e27ff5a173340bddbd8bcf1483a31f4dba5e4387006bf283a9cfdfffebefb60", + "id": "0x3afad17106d68ef22cc302d2bcf243767b6d23c4b0455bab226cf42dab534a6b", "count": "2" } } @@ -546,21 +532,7 @@ Response: { } }, { - "cursor": "IDoFKasvO3uRG36i8kDIIFwQcloILQn2wF4PAQIcTwYqAwAAAAAAAAA=", - "node": { - "name": { - "bcs": "A2RmMg==", - "type": { - "repr": "0x0000000000000000000000000000000000000000000000000000000000000001::string::String" - } - }, - "value": { - "json": "df2" - } - } - }, - { - "cursor": "IJj9WTOaH4fXBwaq2+79tcdTWMlsLD90tAA99wRYadaKAwAAAAAAAAA=", + "cursor": "IIU7dPPcuBqgetb6flqtJ4+c3CCacVg96F3hIFND7GX9AwAAAAAAAAA=", "node": { "name": { "bcs": "A2RmNg==", @@ -574,35 +546,35 @@ Response: { } }, { - "cursor": "ILZJDhqQtyqtQ07tnHozoq0BbJmXlZQypzZ+hHp3ZIBiAwAAAAAAAAA=", + "cursor": "ILOizeXsOFtNA0PsWVFFDc1wNzvV5pHLPGoQ/3+oQ4isAwAAAAAAAAA=", "node": { "name": { - "bcs": "A2RmMQ==", + "bcs": "A2RmNA==", "type": { "repr": "0x0000000000000000000000000000000000000000000000000000000000000001::string::String" } }, "value": { - "json": "df1" + "json": "df4" } } }, { - "cursor": "IMg/FO6gjiPZmCvmjnU/nAaf/yi6/pDjjfvGVfr/lqXOAwAAAAAAAAA=", + "cursor": "INdxBwgkvilBjMxtXP7iG+Ca5Fbl3XI1QmiAEWPxneVGAwAAAAAAAAA=", "node": { "name": { - "bcs": "A2RmNA==", + "bcs": "A2RmMw==", "type": { "repr": "0x0000000000000000000000000000000000000000000000000000000000000001::string::String" } }, "value": { - "json": "df4" + "json": "df3" } } }, { - "cursor": "IN3UrBmzuomvuVn80suIIpOScrO99xrN0GJX752WrurUAwAAAAAAAAA=", + "cursor": "INkGhuK4zepgllnwN5+ylkUrV9r7K2PmgnSqdECS86aaAwAAAAAAAAA=", "node": { "name": { "bcs": "A2RmNQ==", @@ -622,21 +594,7 @@ Response: { "dynamicFields": { "edges": [ { - "cursor": "IDoFKasvO3uRG36i8kDIIFwQcloILQn2wF4PAQIcTwYqAwAAAAAAAAA=", - "node": { - "name": { - "bcs": "A2RmMg==", - "type": { - "repr": "0x0000000000000000000000000000000000000000000000000000000000000001::string::String" - } - }, - "value": { - "json": "df2" - } - } - }, - { - "cursor": "IJj9WTOaH4fXBwaq2+79tcdTWMlsLD90tAA99wRYadaKAwAAAAAAAAA=", + "cursor": "IIU7dPPcuBqgetb6flqtJ4+c3CCacVg96F3hIFND7GX9AwAAAAAAAAA=", "node": { "name": { "bcs": "A2RmNg==", @@ -650,35 +608,35 @@ Response: { } }, { - "cursor": "ILZJDhqQtyqtQ07tnHozoq0BbJmXlZQypzZ+hHp3ZIBiAwAAAAAAAAA=", + "cursor": "ILOizeXsOFtNA0PsWVFFDc1wNzvV5pHLPGoQ/3+oQ4isAwAAAAAAAAA=", "node": { "name": { - "bcs": "A2RmMQ==", + "bcs": "A2RmNA==", "type": { "repr": "0x0000000000000000000000000000000000000000000000000000000000000001::string::String" } }, "value": { - "json": "df1" + "json": "df4" } } }, { - "cursor": "IMg/FO6gjiPZmCvmjnU/nAaf/yi6/pDjjfvGVfr/lqXOAwAAAAAAAAA=", + "cursor": "INdxBwgkvilBjMxtXP7iG+Ca5Fbl3XI1QmiAEWPxneVGAwAAAAAAAAA=", "node": { "name": { - "bcs": "A2RmNA==", + "bcs": "A2RmMw==", "type": { "repr": "0x0000000000000000000000000000000000000000000000000000000000000001::string::String" } }, "value": { - "json": "df4" + "json": "df3" } } }, { - "cursor": "IN3UrBmzuomvuVn80suIIpOScrO99xrN0GJX752WrurUAwAAAAAAAAA=", + "cursor": "INkGhuK4zepgllnwN5+ylkUrV9r7K2PmgnSqdECS86aaAwAAAAAAAAA=", "node": { "name": { "bcs": "A2RmNQ==", @@ -741,63 +699,63 @@ Response: { "dynamicFields": { "edges": [ { - "cursor": "IALh6Gmj1i0tlaFppLIbcxwvTEoesuYprwx6kb++hQptBAAAAAAAAAA=", + "cursor": "IClawurZkDgT+lOfghnjBHn+PLUx66DXjrgRHFWlMokIBAAAAAAAAAA=", "node": { "name": { - "bcs": "A2RmMw==", + "bcs": "A2RmMQ==", "type": { "repr": "0x0000000000000000000000000000000000000000000000000000000000000001::string::String" } }, "value": { - "json": "df3" + "json": "df1" } } }, { - "cursor": "IBkflpr//S+rLcwsf9BrQULoOCUdF2gzhpDlWnLv9dvJBAAAAAAAAAA=", + "cursor": "IEka7584A4U5vrD9MH0Sfiqot3d9S1fFF1xTWGGMOaEkBAAAAAAAAAA=", "node": { "name": { - "bcs": "pAEAAAAAAAA=", + "bcs": "A2RmMg==", "type": { - "repr": "u64" + "repr": "0x0000000000000000000000000000000000000000000000000000000000000001::string::String" } }, "value": { - "contents": { - "json": { - "id": "0x8e27ff5a173340bddbd8bcf1483a31f4dba5e4387006bf283a9cfdfffebefb60", - "count": "2" - } - } + "json": "df2" } } }, { - "cursor": "IDoFKasvO3uRG36i8kDIIFwQcloILQn2wF4PAQIcTwYqBAAAAAAAAAA=", + "cursor": "IFMDN2LB7x4O3i2h+Fjvd5EOi9hYGWmuy0woaBOI9ieiBAAAAAAAAAA=", "node": { "name": { - "bcs": "A2RmMg==", + "bcs": "pAEAAAAAAAA=", "type": { - "repr": "0x0000000000000000000000000000000000000000000000000000000000000001::string::String" + "repr": "u64" } }, "value": { - "json": "df2" + "contents": { + "json": { + "id": "0x3afad17106d68ef22cc302d2bcf243767b6d23c4b0455bab226cf42dab534a6b", + "count": "2" + } + } } } }, { - "cursor": "ILZJDhqQtyqtQ07tnHozoq0BbJmXlZQypzZ+hHp3ZIBiBAAAAAAAAAA=", + "cursor": "INdxBwgkvilBjMxtXP7iG+Ca5Fbl3XI1QmiAEWPxneVGBAAAAAAAAAA=", "node": { "name": { - "bcs": "A2RmMQ==", + "bcs": "A2RmMw==", "type": { "repr": "0x0000000000000000000000000000000000000000000000000000000000000001::string::String" } }, "value": { - "json": "df1" + "json": "df3" } } } @@ -808,30 +766,16 @@ Response: { "dynamicFields": { "edges": [ { - "cursor": "IDoFKasvO3uRG36i8kDIIFwQcloILQn2wF4PAQIcTwYqAgAAAAAAAAA=", + "cursor": "INdxBwgkvilBjMxtXP7iG+Ca5Fbl3XI1QmiAEWPxneVGAgAAAAAAAAA=", "node": { "name": { - "bcs": "A2RmMg==", - "type": { - "repr": "0x0000000000000000000000000000000000000000000000000000000000000001::string::String" - } - }, - "value": { - "json": "df2" - } - } - }, - { - "cursor": "ILZJDhqQtyqtQ07tnHozoq0BbJmXlZQypzZ+hHp3ZIBiAgAAAAAAAAA=", - "node": { - "name": { - "bcs": "A2RmMQ==", + "bcs": "A2RmMw==", "type": { "repr": "0x0000000000000000000000000000000000000000000000000000000000000001::string::String" } }, "value": { - "json": "df1" + "json": "df3" } } } @@ -842,7 +786,7 @@ Response: { "dynamicFields": { "edges": [ { - "cursor": "IBkflpr//S+rLcwsf9BrQULoOCUdF2gzhpDlWnLv9dvJBAAAAAAAAAA=", + "cursor": "IFMDN2LB7x4O3i2h+Fjvd5EOi9hYGWmuy0woaBOI9ieiBAAAAAAAAAA=", "node": { "name": { "bcs": "pAEAAAAAAAA=", @@ -853,7 +797,7 @@ Response: { "value": { "contents": { "json": { - "id": "0x8e27ff5a173340bddbd8bcf1483a31f4dba5e4387006bf283a9cfdfffebefb60", + "id": "0x3afad17106d68ef22cc302d2bcf243767b6d23c4b0455bab226cf42dab534a6b", "count": "2" } } @@ -861,7 +805,7 @@ Response: { } }, { - "cursor": "IJj9WTOaH4fXBwaq2+79tcdTWMlsLD90tAA99wRYadaKBAAAAAAAAAA=", + "cursor": "IIU7dPPcuBqgetb6flqtJ4+c3CCacVg96F3hIFND7GX9BAAAAAAAAAA=", "node": { "name": { "bcs": "A2RmNg==", @@ -875,7 +819,7 @@ Response: { } }, { - "cursor": "IMg/FO6gjiPZmCvmjnU/nAaf/yi6/pDjjfvGVfr/lqXOBAAAAAAAAAA=", + "cursor": "ILOizeXsOFtNA0PsWVFFDc1wNzvV5pHLPGoQ/3+oQ4isBAAAAAAAAAA=", "node": { "name": { "bcs": "A2RmNA==", @@ -889,7 +833,7 @@ Response: { } }, { - "cursor": "IN3UrBmzuomvuVn80suIIpOScrO99xrN0GJX752WrurUBAAAAAAAAAA=", + "cursor": "INkGhuK4zepgllnwN5+ylkUrV9r7K2PmgnSqdECS86aaBAAAAAAAAAA=", "node": { "name": { "bcs": "A2RmNQ==", @@ -909,7 +853,7 @@ Response: { "dynamicFields": { "edges": [ { - "cursor": "IJj9WTOaH4fXBwaq2+79tcdTWMlsLD90tAA99wRYadaKBAAAAAAAAAA=", + "cursor": "IIU7dPPcuBqgetb6flqtJ4+c3CCacVg96F3hIFND7GX9BAAAAAAAAAA=", "node": { "name": { "bcs": "A2RmNg==", @@ -923,7 +867,7 @@ Response: { } }, { - "cursor": "IMg/FO6gjiPZmCvmjnU/nAaf/yi6/pDjjfvGVfr/lqXOBAAAAAAAAAA=", + "cursor": "ILOizeXsOFtNA0PsWVFFDc1wNzvV5pHLPGoQ/3+oQ4isBAAAAAAAAAA=", "node": { "name": { "bcs": "A2RmNA==", @@ -937,7 +881,7 @@ Response: { } }, { - "cursor": "IN3UrBmzuomvuVn80suIIpOScrO99xrN0GJX752WrurUBAAAAAAAAAA=", + "cursor": "INkGhuK4zepgllnwN5+ylkUrV9r7K2PmgnSqdECS86aaBAAAAAAAAAA=", "node": { "name": { "bcs": "A2RmNQ==", @@ -1003,7 +947,7 @@ Response: { "dynamicFields": { "edges": [ { - "cursor": "IBkflpr//S+rLcwsf9BrQULoOCUdF2gzhpDlWnLv9dvJBwAAAAAAAAA=", + "cursor": "IFMDN2LB7x4O3i2h+Fjvd5EOi9hYGWmuy0woaBOI9ieiBwAAAAAAAAA=", "node": { "name": { "bcs": "pAEAAAAAAAA=", @@ -1014,7 +958,7 @@ Response: { "value": { "contents": { "json": { - "id": "0x8e27ff5a173340bddbd8bcf1483a31f4dba5e4387006bf283a9cfdfffebefb60", + "id": "0x3afad17106d68ef22cc302d2bcf243767b6d23c4b0455bab226cf42dab534a6b", "count": "2" } } @@ -1029,7 +973,7 @@ Response: { "dynamicFields": { "edges": [ { - "cursor": "IBkflpr//S+rLcwsf9BrQULoOCUdF2gzhpDlWnLv9dvJBwAAAAAAAAA=", + "cursor": "IFMDN2LB7x4O3i2h+Fjvd5EOi9hYGWmuy0woaBOI9ieiBwAAAAAAAAA=", "node": { "name": { "bcs": "pAEAAAAAAAA=", @@ -1040,7 +984,7 @@ Response: { "value": { "contents": { "json": { - "id": "0x8e27ff5a173340bddbd8bcf1483a31f4dba5e4387006bf283a9cfdfffebefb60", + "id": "0x3afad17106d68ef22cc302d2bcf243767b6d23c4b0455bab226cf42dab534a6b", "count": "2" } } @@ -1048,7 +992,7 @@ Response: { } }, { - "cursor": "IJj9WTOaH4fXBwaq2+79tcdTWMlsLD90tAA99wRYadaKBwAAAAAAAAA=", + "cursor": "IIU7dPPcuBqgetb6flqtJ4+c3CCacVg96F3hIFND7GX9BwAAAAAAAAA=", "node": { "name": { "bcs": "A2RmNg==", @@ -1062,7 +1006,7 @@ Response: { } }, { - "cursor": "IMg/FO6gjiPZmCvmjnU/nAaf/yi6/pDjjfvGVfr/lqXOBwAAAAAAAAA=", + "cursor": "ILOizeXsOFtNA0PsWVFFDc1wNzvV5pHLPGoQ/3+oQ4isBwAAAAAAAAA=", "node": { "name": { "bcs": "A2RmNA==", @@ -1076,7 +1020,7 @@ Response: { } }, { - "cursor": "IN3UrBmzuomvuVn80suIIpOScrO99xrN0GJX752WrurUBwAAAAAAAAA=", + "cursor": "INkGhuK4zepgllnwN5+ylkUrV9r7K2PmgnSqdECS86aaBwAAAAAAAAA=", "node": { "name": { "bcs": "A2RmNQ==", @@ -1096,7 +1040,7 @@ Response: { "dynamicFields": { "edges": [ { - "cursor": "IJj9WTOaH4fXBwaq2+79tcdTWMlsLD90tAA99wRYadaKBAAAAAAAAAA=", + "cursor": "IIU7dPPcuBqgetb6flqtJ4+c3CCacVg96F3hIFND7GX9BAAAAAAAAAA=", "node": { "name": { "bcs": "A2RmNg==", @@ -1110,7 +1054,7 @@ Response: { } }, { - "cursor": "IMg/FO6gjiPZmCvmjnU/nAaf/yi6/pDjjfvGVfr/lqXOBAAAAAAAAAA=", + "cursor": "ILOizeXsOFtNA0PsWVFFDc1wNzvV5pHLPGoQ/3+oQ4isBAAAAAAAAAA=", "node": { "name": { "bcs": "A2RmNA==", @@ -1124,7 +1068,7 @@ Response: { } }, { - "cursor": "IN3UrBmzuomvuVn80suIIpOScrO99xrN0GJX752WrurUBAAAAAAAAAA=", + "cursor": "INkGhuK4zepgllnwN5+ylkUrV9r7K2PmgnSqdECS86aaBAAAAAAAAAA=", "node": { "name": { "bcs": "A2RmNQ==", diff --git a/crates/iota-graphql-e2e-tests/tests/consistency/dynamic_fields/immutable_dof.exp b/crates/iota-graphql-e2e-tests/tests/consistency/dynamic_fields/immutable_dof.exp index fff4c15b7b7..0af1dde53cf 100644 --- a/crates/iota-graphql-e2e-tests/tests/consistency/dynamic_fields/immutable_dof.exp +++ b/crates/iota-graphql-e2e-tests/tests/consistency/dynamic_fields/immutable_dof.exp @@ -58,11 +58,11 @@ Response: { "nodes": [ { "value": { - "address": "0x8603ad20d654d0c0c01565eea9c2e60ef1c3451d8039ccb82b766b1bbe0b1b63", + "address": "0xaff6dda50b5130810c03f46780c788a2a7cd585ee4581f95987b935927d1fe1f", "version": 5, "contents": { "json": { - "id": "0x8603ad20d654d0c0c01565eea9c2e60ef1c3451d8039ccb82b766b1bbe0b1b63", + "id": "0xaff6dda50b5130810c03f46780c788a2a7cd585ee4581f95987b935927d1fe1f", "count": "0" } }, @@ -86,11 +86,11 @@ Response: { "nodes": [ { "value": { - "address": "0x8603ad20d654d0c0c01565eea9c2e60ef1c3451d8039ccb82b766b1bbe0b1b63", + "address": "0xaff6dda50b5130810c03f46780c788a2a7cd585ee4581f95987b935927d1fe1f", "version": 5, "contents": { "json": { - "id": "0x8603ad20d654d0c0c01565eea9c2e60ef1c3451d8039ccb82b766b1bbe0b1b63", + "id": "0xaff6dda50b5130810c03f46780c788a2a7cd585ee4581f95987b935927d1fe1f", "count": "0" } }, @@ -98,11 +98,11 @@ Response: { "nodes": [ { "value": { - "address": "0xf951c0b6f5ab4e8bee9eb5e914129387a884624132c454575d203d545691a5a2", + "address": "0xfaef186e54a8fa552021ab48bb81ceec2fd48da225c79daf74ecd2f3c8f5bc62", "version": 6, "contents": { "json": { - "id": "0xf951c0b6f5ab4e8bee9eb5e914129387a884624132c454575d203d545691a5a2", + "id": "0xfaef186e54a8fa552021ab48bb81ceec2fd48da225c79daf74ecd2f3c8f5bc62", "count": "0" } } @@ -145,7 +145,7 @@ Response: { "object": { "owner": { "parent": { - "address": "0x31c25614224e45aadeb93d9117cb1485b4e37dde7649eb6f1145cad43eef6057" + "address": "0x1de03df5ffee42e90111e8d70c09bcb730067c0454de43126b4268a3d52ce49d" } }, "dynamicFields": { @@ -175,11 +175,11 @@ Response: { "nodes": [ { "value": { - "address": "0xf951c0b6f5ab4e8bee9eb5e914129387a884624132c454575d203d545691a5a2", + "address": "0xfaef186e54a8fa552021ab48bb81ceec2fd48da225c79daf74ecd2f3c8f5bc62", "version": 6, "contents": { "json": { - "id": "0xf951c0b6f5ab4e8bee9eb5e914129387a884624132c454575d203d545691a5a2", + "id": "0xfaef186e54a8fa552021ab48bb81ceec2fd48da225c79daf74ecd2f3c8f5bc62", "count": "0" } } @@ -203,11 +203,11 @@ Response: { "nodes": [ { "value": { - "address": "0xf951c0b6f5ab4e8bee9eb5e914129387a884624132c454575d203d545691a5a2", + "address": "0xfaef186e54a8fa552021ab48bb81ceec2fd48da225c79daf74ecd2f3c8f5bc62", "version": 6, "contents": { "json": { - "id": "0xf951c0b6f5ab4e8bee9eb5e914129387a884624132c454575d203d545691a5a2", + "id": "0xfaef186e54a8fa552021ab48bb81ceec2fd48da225c79daf74ecd2f3c8f5bc62", "count": "0" } } diff --git a/crates/iota-graphql-e2e-tests/tests/consistency/dynamic_fields/mutated_df.exp b/crates/iota-graphql-e2e-tests/tests/consistency/dynamic_fields/mutated_df.exp index 495afe8ec2a..7ac216366d3 100644 --- a/crates/iota-graphql-e2e-tests/tests/consistency/dynamic_fields/mutated_df.exp +++ b/crates/iota-graphql-e2e-tests/tests/consistency/dynamic_fields/mutated_df.exp @@ -78,7 +78,7 @@ Response: { "dynamicFields": { "edges": [ { - "cursor": "ICL7pJfAQLj6WYX7JFqe8xzFC/CvS5IAKLUxLQMjEDPMAQAAAAAAAAA=", + "cursor": "IELBJuoqbljOwtDZvYNmHAhFckzJMAyIckHHx4VWEQmAAQAAAAAAAAA=", "node": { "name": { "bcs": "A2RmMw==" @@ -89,7 +89,7 @@ Response: { } }, { - "cursor": "IDDmzOHqC1rNbC7svj9ulnV/RJFyPyAyQ1aRX/whHumNAQAAAAAAAAA=", + "cursor": "IE50PYtWegIrApc+e7eCSzFWzucYLDr5EFXOGSku7+5JAQAAAAAAAAA=", "node": { "name": { "bcs": "A2RmMg==" @@ -100,7 +100,7 @@ Response: { } }, { - "cursor": "IIVQTTVQjMUkDYOy1/VGNfpBmQxaJo6M0SMfHyrWrbGAAQAAAAAAAAA=", + "cursor": "IHV1hfusMCdIxYwdoOX894dzfghsSphPFaIm4ekstxexAQAAAAAAAAA=", "node": { "name": { "bcs": "A2RmMQ==" @@ -201,7 +201,7 @@ Response: { "dynamicFields": { "edges": [ { - "cursor": "ICL7pJfAQLj6WYX7JFqe8xzFC/CvS5IAKLUxLQMjEDPMAgAAAAAAAAA=", + "cursor": "IELBJuoqbljOwtDZvYNmHAhFckzJMAyIckHHx4VWEQmAAgAAAAAAAAA=", "node": { "name": { "bcs": "A2RmMw==" @@ -212,7 +212,7 @@ Response: { } }, { - "cursor": "IDDmzOHqC1rNbC7svj9ulnV/RJFyPyAyQ1aRX/whHumNAgAAAAAAAAA=", + "cursor": "IE50PYtWegIrApc+e7eCSzFWzucYLDr5EFXOGSku7+5JAgAAAAAAAAA=", "node": { "name": { "bcs": "A2RmMg==" @@ -223,7 +223,7 @@ Response: { } }, { - "cursor": "IIVQTTVQjMUkDYOy1/VGNfpBmQxaJo6M0SMfHyrWrbGAAgAAAAAAAAA=", + "cursor": "IHV1hfusMCdIxYwdoOX894dzfghsSphPFaIm4ekstxexAgAAAAAAAAA=", "node": { "name": { "bcs": "A2RmMQ==" diff --git a/crates/iota-graphql-e2e-tests/tests/consistency/dynamic_fields/mutated_dof.exp b/crates/iota-graphql-e2e-tests/tests/consistency/dynamic_fields/mutated_dof.exp index 096fa5aa5cc..609ba4609fe 100644 --- a/crates/iota-graphql-e2e-tests/tests/consistency/dynamic_fields/mutated_dof.exp +++ b/crates/iota-graphql-e2e-tests/tests/consistency/dynamic_fields/mutated_dof.exp @@ -41,7 +41,7 @@ Response: { "dynamicFields": { "edges": [ { - "cursor": "IDyE8cX8asJQ38Rt/kwo8heuhhDsWyl1CHjK/D32HvIxAQAAAAAAAAA=", + "cursor": "IILk4DoK3o6yrxAwN0nWEvtu/px9bonymP5hhiRzZimMAQAAAAAAAAA=", "node": { "name": { "bcs": "KgAAAAAAAAA=" @@ -49,7 +49,7 @@ Response: { "value": { "contents": { "json": { - "id": "0x4df431020b1db28d623c6129f55c56c5664a167913fe46fce4bed4c0e1cd5c3b", + "id": "0x4d27bedb2ae9374644eb6e8066beee687ecd6af723928782e972f40ef683b5d1", "count": "0" } } @@ -65,7 +65,7 @@ Response: { "value": { "contents": { "json": { - "id": "0x4df431020b1db28d623c6129f55c56c5664a167913fe46fce4bed4c0e1cd5c3b", + "id": "0x4d27bedb2ae9374644eb6e8066beee687ecd6af723928782e972f40ef683b5d1", "count": "0" } } @@ -77,7 +77,7 @@ Response: { "dynamicFields": { "edges": [ { - "cursor": "IDyE8cX8asJQ38Rt/kwo8heuhhDsWyl1CHjK/D32HvIxAQAAAAAAAAA=", + "cursor": "IILk4DoK3o6yrxAwN0nWEvtu/px9bonymP5hhiRzZimMAQAAAAAAAAA=", "node": { "name": { "bcs": "KgAAAAAAAAA=" @@ -85,7 +85,7 @@ Response: { "value": { "contents": { "json": { - "id": "0x4df431020b1db28d623c6129f55c56c5664a167913fe46fce4bed4c0e1cd5c3b", + "id": "0x4d27bedb2ae9374644eb6e8066beee687ecd6af723928782e972f40ef683b5d1", "count": "0" } } @@ -101,7 +101,7 @@ Response: { "value": { "contents": { "json": { - "id": "0x4df431020b1db28d623c6129f55c56c5664a167913fe46fce4bed4c0e1cd5c3b", + "id": "0x4d27bedb2ae9374644eb6e8066beee687ecd6af723928782e972f40ef683b5d1", "count": "0" } } @@ -117,7 +117,7 @@ Response: { "value": { "contents": { "json": { - "id": "0x4df431020b1db28d623c6129f55c56c5664a167913fe46fce4bed4c0e1cd5c3b", + "id": "0x4d27bedb2ae9374644eb6e8066beee687ecd6af723928782e972f40ef683b5d1", "count": "0" } } @@ -168,7 +168,7 @@ Response: { "value": { "contents": { "json": { - "id": "0x4df431020b1db28d623c6129f55c56c5664a167913fe46fce4bed4c0e1cd5c3b", + "id": "0x4d27bedb2ae9374644eb6e8066beee687ecd6af723928782e972f40ef683b5d1", "count": "0" } } @@ -202,7 +202,7 @@ Response: { "dynamicFields": { "edges": [ { - "cursor": "IDyE8cX8asJQ38Rt/kwo8heuhhDsWyl1CHjK/D32HvIxAwAAAAAAAAA=", + "cursor": "IILk4DoK3o6yrxAwN0nWEvtu/px9bonymP5hhiRzZimMAwAAAAAAAAA=", "node": { "name": { "bcs": "KgAAAAAAAAA=" @@ -210,7 +210,7 @@ Response: { "value": { "contents": { "json": { - "id": "0x4df431020b1db28d623c6129f55c56c5664a167913fe46fce4bed4c0e1cd5c3b", + "id": "0x4d27bedb2ae9374644eb6e8066beee687ecd6af723928782e972f40ef683b5d1", "count": "1" } } @@ -226,7 +226,7 @@ Response: { "value": { "contents": { "json": { - "id": "0x4df431020b1db28d623c6129f55c56c5664a167913fe46fce4bed4c0e1cd5c3b", + "id": "0x4d27bedb2ae9374644eb6e8066beee687ecd6af723928782e972f40ef683b5d1", "count": "1" } } @@ -238,7 +238,7 @@ Response: { "dynamicFields": { "edges": [ { - "cursor": "IDyE8cX8asJQ38Rt/kwo8heuhhDsWyl1CHjK/D32HvIxAwAAAAAAAAA=", + "cursor": "IILk4DoK3o6yrxAwN0nWEvtu/px9bonymP5hhiRzZimMAwAAAAAAAAA=", "node": { "name": { "bcs": "KgAAAAAAAAA=" @@ -246,7 +246,7 @@ Response: { "value": { "contents": { "json": { - "id": "0x4df431020b1db28d623c6129f55c56c5664a167913fe46fce4bed4c0e1cd5c3b", + "id": "0x4d27bedb2ae9374644eb6e8066beee687ecd6af723928782e972f40ef683b5d1", "count": "1" } } @@ -262,7 +262,7 @@ Response: { "value": { "contents": { "json": { - "id": "0x4df431020b1db28d623c6129f55c56c5664a167913fe46fce4bed4c0e1cd5c3b", + "id": "0x4d27bedb2ae9374644eb6e8066beee687ecd6af723928782e972f40ef683b5d1", "count": "1" } } @@ -283,7 +283,7 @@ Response: { "value": { "contents": { "json": { - "id": "0x4df431020b1db28d623c6129f55c56c5664a167913fe46fce4bed4c0e1cd5c3b", + "id": "0x4d27bedb2ae9374644eb6e8066beee687ecd6af723928782e972f40ef683b5d1", "count": "0" } } diff --git a/crates/iota-graphql-e2e-tests/tests/consistency/dynamic_fields/nested_dof.exp b/crates/iota-graphql-e2e-tests/tests/consistency/dynamic_fields/nested_dof.exp index 1bf5bd620cd..d3d313eded0 100644 --- a/crates/iota-graphql-e2e-tests/tests/consistency/dynamic_fields/nested_dof.exp +++ b/crates/iota-graphql-e2e-tests/tests/consistency/dynamic_fields/nested_dof.exp @@ -62,11 +62,11 @@ Response: { "nodes": [ { "value": { - "address": "0x615e8039a1bf2fd65fc04d18cb2513e55837a421b1e39bd309d2b6fd3b8986a8", + "address": "0xb23e265ad3de2915b71beaed9646ac55bc5884e8280cfe0fca729a6ff86ce622", "version": 5, "contents": { "json": { - "id": "0x615e8039a1bf2fd65fc04d18cb2513e55837a421b1e39bd309d2b6fd3b8986a8", + "id": "0xb23e265ad3de2915b71beaed9646ac55bc5884e8280cfe0fca729a6ff86ce622", "count": "0" } }, @@ -90,11 +90,11 @@ Response: { "nodes": [ { "value": { - "address": "0x615e8039a1bf2fd65fc04d18cb2513e55837a421b1e39bd309d2b6fd3b8986a8", + "address": "0xb23e265ad3de2915b71beaed9646ac55bc5884e8280cfe0fca729a6ff86ce622", "version": 5, "contents": { "json": { - "id": "0x615e8039a1bf2fd65fc04d18cb2513e55837a421b1e39bd309d2b6fd3b8986a8", + "id": "0xb23e265ad3de2915b71beaed9646ac55bc5884e8280cfe0fca729a6ff86ce622", "count": "0" } }, @@ -102,11 +102,11 @@ Response: { "nodes": [ { "value": { - "address": "0xc2dd55dcfaacddef3f214a2c31824b6b9b3c4bbd473718de32a7020d6311435e", + "address": "0xb11df24f6316d9054942a64b67fdf27ad90f9ec870efc4ad7e81237730497300", "version": 6, "contents": { "json": { - "id": "0xc2dd55dcfaacddef3f214a2c31824b6b9b3c4bbd473718de32a7020d6311435e", + "id": "0xb11df24f6316d9054942a64b67fdf27ad90f9ec870efc4ad7e81237730497300", "count": "0" } } @@ -131,11 +131,11 @@ Response: { "nodes": [ { "value": { - "address": "0x615e8039a1bf2fd65fc04d18cb2513e55837a421b1e39bd309d2b6fd3b8986a8", + "address": "0xb23e265ad3de2915b71beaed9646ac55bc5884e8280cfe0fca729a6ff86ce622", "version": 7, "contents": { "json": { - "id": "0x615e8039a1bf2fd65fc04d18cb2513e55837a421b1e39bd309d2b6fd3b8986a8", + "id": "0xb23e265ad3de2915b71beaed9646ac55bc5884e8280cfe0fca729a6ff86ce622", "count": "1" } }, @@ -143,11 +143,11 @@ Response: { "nodes": [ { "value": { - "address": "0xc2dd55dcfaacddef3f214a2c31824b6b9b3c4bbd473718de32a7020d6311435e", + "address": "0xb11df24f6316d9054942a64b67fdf27ad90f9ec870efc4ad7e81237730497300", "version": 6, "contents": { "json": { - "id": "0xc2dd55dcfaacddef3f214a2c31824b6b9b3c4bbd473718de32a7020d6311435e", + "id": "0xb11df24f6316d9054942a64b67fdf27ad90f9ec870efc4ad7e81237730497300", "count": "0" } } @@ -172,11 +172,11 @@ Response: { "nodes": [ { "value": { - "address": "0x615e8039a1bf2fd65fc04d18cb2513e55837a421b1e39bd309d2b6fd3b8986a8", + "address": "0xb23e265ad3de2915b71beaed9646ac55bc5884e8280cfe0fca729a6ff86ce622", "version": 7, "contents": { "json": { - "id": "0x615e8039a1bf2fd65fc04d18cb2513e55837a421b1e39bd309d2b6fd3b8986a8", + "id": "0xb23e265ad3de2915b71beaed9646ac55bc5884e8280cfe0fca729a6ff86ce622", "count": "1" } }, @@ -184,11 +184,11 @@ Response: { "nodes": [ { "value": { - "address": "0xc2dd55dcfaacddef3f214a2c31824b6b9b3c4bbd473718de32a7020d6311435e", + "address": "0xb11df24f6316d9054942a64b67fdf27ad90f9ec870efc4ad7e81237730497300", "version": 8, "contents": { "json": { - "id": "0xc2dd55dcfaacddef3f214a2c31824b6b9b3c4bbd473718de32a7020d6311435e", + "id": "0xb11df24f6316d9054942a64b67fdf27ad90f9ec870efc4ad7e81237730497300", "count": "1" } } @@ -233,11 +233,11 @@ Response: { "nodes": [ { "value": { - "address": "0xc2dd55dcfaacddef3f214a2c31824b6b9b3c4bbd473718de32a7020d6311435e", + "address": "0xb11df24f6316d9054942a64b67fdf27ad90f9ec870efc4ad7e81237730497300", "version": 6, "contents": { "json": { - "id": "0xc2dd55dcfaacddef3f214a2c31824b6b9b3c4bbd473718de32a7020d6311435e", + "id": "0xb11df24f6316d9054942a64b67fdf27ad90f9ec870efc4ad7e81237730497300", "count": "0" } } diff --git a/crates/iota-graphql-e2e-tests/tests/consistency/epochs/transaction_blocks.exp b/crates/iota-graphql-e2e-tests/tests/consistency/epochs/transaction_blocks.exp index b45454f5e94..3c0d96d8629 100644 --- a/crates/iota-graphql-e2e-tests/tests/consistency/epochs/transaction_blocks.exp +++ b/crates/iota-graphql-e2e-tests/tests/consistency/epochs/transaction_blocks.exp @@ -41,19 +41,19 @@ Response: { { "cursor": "eyJjIjozLCJ0IjowLCJpIjpmYWxzZX0", "node": { - "digest": "8twBu7kvzDbfSLjpBJ2GbDpfARJpwkdVCywZJqQCc3Eu" + "digest": "b5R95kKQ5woMzx3Qv8GjKKG7JZZLLsg1DAFkuKULx7V" } }, { "cursor": "eyJjIjozLCJ0IjoxLCJpIjpmYWxzZX0", "node": { - "digest": "8fpjvnkVGNNbPNqNiB865VayCFzpvvtNkHWYWYAWWAZw" + "digest": "Hq1LQh51ZhntdNmuXMyMfKp6GAwWeMiS1HMYeJTuXoxc" } }, { "cursor": "eyJjIjozLCJ0IjoyLCJpIjpmYWxzZX0", "node": { - "digest": "3Wu2rNcM39pocoovpHUXZrWtwQXn8ZXAGpwrU7GthLLD" + "digest": "79od1gfpa4bdobeR94ZQ38ea2SbKVrnYo4KiRpUKZKyB" } }, { @@ -154,19 +154,19 @@ Response: { { "cursor": "eyJjIjoxMiwidCI6MCwiaSI6ZmFsc2V9", "node": { - "digest": "8twBu7kvzDbfSLjpBJ2GbDpfARJpwkdVCywZJqQCc3Eu" + "digest": "b5R95kKQ5woMzx3Qv8GjKKG7JZZLLsg1DAFkuKULx7V" } }, { "cursor": "eyJjIjoxMiwidCI6MSwiaSI6ZmFsc2V9", "node": { - "digest": "8fpjvnkVGNNbPNqNiB865VayCFzpvvtNkHWYWYAWWAZw" + "digest": "Hq1LQh51ZhntdNmuXMyMfKp6GAwWeMiS1HMYeJTuXoxc" } }, { "cursor": "eyJjIjoxMiwidCI6MiwiaSI6ZmFsc2V9", "node": { - "digest": "3Wu2rNcM39pocoovpHUXZrWtwQXn8ZXAGpwrU7GthLLD" + "digest": "79od1gfpa4bdobeR94ZQ38ea2SbKVrnYo4KiRpUKZKyB" } }, { @@ -183,19 +183,19 @@ Response: { { "cursor": "eyJjIjo0LCJ0IjowLCJpIjpmYWxzZX0", "node": { - "digest": "8twBu7kvzDbfSLjpBJ2GbDpfARJpwkdVCywZJqQCc3Eu" + "digest": "b5R95kKQ5woMzx3Qv8GjKKG7JZZLLsg1DAFkuKULx7V" } }, { "cursor": "eyJjIjo0LCJ0IjoxLCJpIjpmYWxzZX0", "node": { - "digest": "8fpjvnkVGNNbPNqNiB865VayCFzpvvtNkHWYWYAWWAZw" + "digest": "Hq1LQh51ZhntdNmuXMyMfKp6GAwWeMiS1HMYeJTuXoxc" } }, { "cursor": "eyJjIjo0LCJ0IjoyLCJpIjpmYWxzZX0", "node": { - "digest": "3Wu2rNcM39pocoovpHUXZrWtwQXn8ZXAGpwrU7GthLLD" + "digest": "79od1gfpa4bdobeR94ZQ38ea2SbKVrnYo4KiRpUKZKyB" } } ] @@ -207,19 +207,19 @@ Response: { { "cursor": "eyJjIjoxMiwidCI6NCwiaSI6ZmFsc2V9", "node": { - "digest": "5Fx8EKmMoiHb59rVr2ch64EgLyvs9SWhuUHq6x3HAx3T" + "digest": "7qGUBfHDs1CziLgVJBXamBawVtztiyp2sAPdaRWiPNT1" } }, { "cursor": "eyJjIjoxMiwidCI6NSwiaSI6ZmFsc2V9", "node": { - "digest": "DvNBuuqGugb9p76oMb1jLa6MdAv7mT184x69bGKC2rQw" + "digest": "BMAW5GS7peWfXNwjcNKYfRqWDJ5Mb7eY61o1KMcozhFG" } }, { "cursor": "eyJjIjoxMiwidCI6NiwiaSI6ZmFsc2V9", "node": { - "digest": "ERSRy9F3o39NCDRWeDVz5AgBGZPmaCdXzzJ6tjd8eY7k" + "digest": "6dR6sJWFBCVAf65zvqJAZBwViUT1PdjmgWmPckqWHtpg" } }, { @@ -236,19 +236,19 @@ Response: { { "cursor": "eyJjIjo4LCJ0IjowLCJpIjpmYWxzZX0", "node": { - "digest": "8twBu7kvzDbfSLjpBJ2GbDpfARJpwkdVCywZJqQCc3Eu" + "digest": "b5R95kKQ5woMzx3Qv8GjKKG7JZZLLsg1DAFkuKULx7V" } }, { "cursor": "eyJjIjo4LCJ0IjoxLCJpIjpmYWxzZX0", "node": { - "digest": "8fpjvnkVGNNbPNqNiB865VayCFzpvvtNkHWYWYAWWAZw" + "digest": "Hq1LQh51ZhntdNmuXMyMfKp6GAwWeMiS1HMYeJTuXoxc" } }, { "cursor": "eyJjIjo4LCJ0IjoyLCJpIjpmYWxzZX0", "node": { - "digest": "3Wu2rNcM39pocoovpHUXZrWtwQXn8ZXAGpwrU7GthLLD" + "digest": "79od1gfpa4bdobeR94ZQ38ea2SbKVrnYo4KiRpUKZKyB" } }, { @@ -260,19 +260,19 @@ Response: { { "cursor": "eyJjIjo4LCJ0Ijo0LCJpIjpmYWxzZX0", "node": { - "digest": "5Fx8EKmMoiHb59rVr2ch64EgLyvs9SWhuUHq6x3HAx3T" + "digest": "7qGUBfHDs1CziLgVJBXamBawVtztiyp2sAPdaRWiPNT1" } }, { "cursor": "eyJjIjo4LCJ0Ijo1LCJpIjpmYWxzZX0", "node": { - "digest": "DvNBuuqGugb9p76oMb1jLa6MdAv7mT184x69bGKC2rQw" + "digest": "BMAW5GS7peWfXNwjcNKYfRqWDJ5Mb7eY61o1KMcozhFG" } }, { "cursor": "eyJjIjo4LCJ0Ijo2LCJpIjpmYWxzZX0", "node": { - "digest": "ERSRy9F3o39NCDRWeDVz5AgBGZPmaCdXzzJ6tjd8eY7k" + "digest": "6dR6sJWFBCVAf65zvqJAZBwViUT1PdjmgWmPckqWHtpg" } } ] @@ -284,19 +284,19 @@ Response: { { "cursor": "eyJjIjoxMiwidCI6OCwiaSI6ZmFsc2V9", "node": { - "digest": "2uLirA5sxREeS1UHEKCJWeoMv2R1MKCUiiep9Q6s7WA6" + "digest": "5mUu9bxNaotcEsssawXpQWZ5Rd2RkjbssbZHy4YqP6jj" } }, { "cursor": "eyJjIjoxMiwidCI6OSwiaSI6ZmFsc2V9", "node": { - "digest": "4HgxdMoiQdZbLrd7ycQ3csPtccNPvr9BZW67ykV7NRk6" + "digest": "26L1PsnhdXmQHEgRiqw9WTMmFZy8CJUjta7yGuuvH7DD" } }, { "cursor": "eyJjIjoxMiwidCI6MTAsImkiOmZhbHNlfQ", "node": { - "digest": "d9yohmp3svrBRKZjbfv7Gn5TbCrmspbqis2wy76ES1M" + "digest": "9Rztd6zgt6r1kZ5hUPALhi8K2ZXBBDj8d2aF3cemSZCP" } }, { @@ -313,19 +313,19 @@ Response: { { "cursor": "eyJjIjoxMiwidCI6MCwiaSI6ZmFsc2V9", "node": { - "digest": "8twBu7kvzDbfSLjpBJ2GbDpfARJpwkdVCywZJqQCc3Eu" + "digest": "b5R95kKQ5woMzx3Qv8GjKKG7JZZLLsg1DAFkuKULx7V" } }, { "cursor": "eyJjIjoxMiwidCI6MSwiaSI6ZmFsc2V9", "node": { - "digest": "8fpjvnkVGNNbPNqNiB865VayCFzpvvtNkHWYWYAWWAZw" + "digest": "Hq1LQh51ZhntdNmuXMyMfKp6GAwWeMiS1HMYeJTuXoxc" } }, { "cursor": "eyJjIjoxMiwidCI6MiwiaSI6ZmFsc2V9", "node": { - "digest": "3Wu2rNcM39pocoovpHUXZrWtwQXn8ZXAGpwrU7GthLLD" + "digest": "79od1gfpa4bdobeR94ZQ38ea2SbKVrnYo4KiRpUKZKyB" } }, { @@ -337,19 +337,19 @@ Response: { { "cursor": "eyJjIjoxMiwidCI6NCwiaSI6ZmFsc2V9", "node": { - "digest": "5Fx8EKmMoiHb59rVr2ch64EgLyvs9SWhuUHq6x3HAx3T" + "digest": "7qGUBfHDs1CziLgVJBXamBawVtztiyp2sAPdaRWiPNT1" } }, { "cursor": "eyJjIjoxMiwidCI6NSwiaSI6ZmFsc2V9", "node": { - "digest": "DvNBuuqGugb9p76oMb1jLa6MdAv7mT184x69bGKC2rQw" + "digest": "BMAW5GS7peWfXNwjcNKYfRqWDJ5Mb7eY61o1KMcozhFG" } }, { "cursor": "eyJjIjoxMiwidCI6NiwiaSI6ZmFsc2V9", "node": { - "digest": "ERSRy9F3o39NCDRWeDVz5AgBGZPmaCdXzzJ6tjd8eY7k" + "digest": "6dR6sJWFBCVAf65zvqJAZBwViUT1PdjmgWmPckqWHtpg" } }, { @@ -361,19 +361,19 @@ Response: { { "cursor": "eyJjIjoxMiwidCI6OCwiaSI6ZmFsc2V9", "node": { - "digest": "2uLirA5sxREeS1UHEKCJWeoMv2R1MKCUiiep9Q6s7WA6" + "digest": "5mUu9bxNaotcEsssawXpQWZ5Rd2RkjbssbZHy4YqP6jj" } }, { "cursor": "eyJjIjoxMiwidCI6OSwiaSI6ZmFsc2V9", "node": { - "digest": "4HgxdMoiQdZbLrd7ycQ3csPtccNPvr9BZW67ykV7NRk6" + "digest": "26L1PsnhdXmQHEgRiqw9WTMmFZy8CJUjta7yGuuvH7DD" } }, { "cursor": "eyJjIjoxMiwidCI6MTAsImkiOmZhbHNlfQ", "node": { - "digest": "d9yohmp3svrBRKZjbfv7Gn5TbCrmspbqis2wy76ES1M" + "digest": "9Rztd6zgt6r1kZ5hUPALhi8K2ZXBBDj8d2aF3cemSZCP" } } ] @@ -395,13 +395,13 @@ Response: { { "cursor": "eyJjIjo3LCJ0IjoxLCJpIjpmYWxzZX0", "node": { - "digest": "8fpjvnkVGNNbPNqNiB865VayCFzpvvtNkHWYWYAWWAZw" + "digest": "Hq1LQh51ZhntdNmuXMyMfKp6GAwWeMiS1HMYeJTuXoxc" } }, { "cursor": "eyJjIjo3LCJ0IjoyLCJpIjpmYWxzZX0", "node": { - "digest": "3Wu2rNcM39pocoovpHUXZrWtwQXn8ZXAGpwrU7GthLLD" + "digest": "79od1gfpa4bdobeR94ZQ38ea2SbKVrnYo4KiRpUKZKyB" } }, { @@ -420,13 +420,13 @@ Response: { { "cursor": "eyJjIjoxMSwidCI6NSwiaSI6ZmFsc2V9", "node": { - "digest": "DvNBuuqGugb9p76oMb1jLa6MdAv7mT184x69bGKC2rQw" + "digest": "BMAW5GS7peWfXNwjcNKYfRqWDJ5Mb7eY61o1KMcozhFG" } }, { "cursor": "eyJjIjoxMSwidCI6NiwiaSI6ZmFsc2V9", "node": { - "digest": "ERSRy9F3o39NCDRWeDVz5AgBGZPmaCdXzzJ6tjd8eY7k" + "digest": "6dR6sJWFBCVAf65zvqJAZBwViUT1PdjmgWmPckqWHtpg" } }, { @@ -445,13 +445,13 @@ Response: { { "cursor": "eyJjIjoxMiwidCI6OSwiaSI6ZmFsc2V9", "node": { - "digest": "4HgxdMoiQdZbLrd7ycQ3csPtccNPvr9BZW67ykV7NRk6" + "digest": "26L1PsnhdXmQHEgRiqw9WTMmFZy8CJUjta7yGuuvH7DD" } }, { "cursor": "eyJjIjoxMiwidCI6MTAsImkiOmZhbHNlfQ", "node": { - "digest": "d9yohmp3svrBRKZjbfv7Gn5TbCrmspbqis2wy76ES1M" + "digest": "9Rztd6zgt6r1kZ5hUPALhi8K2ZXBBDj8d2aF3cemSZCP" } }, { @@ -480,7 +480,7 @@ Response: { { "cursor": "eyJjIjoyLCJ0IjoyLCJpIjpmYWxzZX0", "node": { - "digest": "3Wu2rNcM39pocoovpHUXZrWtwQXn8ZXAGpwrU7GthLLD" + "digest": "79od1gfpa4bdobeR94ZQ38ea2SbKVrnYo4KiRpUKZKyB" } } ] @@ -493,7 +493,7 @@ Response: { { "cursor": "eyJjIjo2LCJ0Ijo2LCJpIjpmYWxzZX0", "node": { - "digest": "ERSRy9F3o39NCDRWeDVz5AgBGZPmaCdXzzJ6tjd8eY7k" + "digest": "6dR6sJWFBCVAf65zvqJAZBwViUT1PdjmgWmPckqWHtpg" } } ] @@ -506,7 +506,7 @@ Response: { { "cursor": "eyJjIjoxMCwidCI6MTAsImkiOmZhbHNlfQ", "node": { - "digest": "d9yohmp3svrBRKZjbfv7Gn5TbCrmspbqis2wy76ES1M" + "digest": "9Rztd6zgt6r1kZ5hUPALhi8K2ZXBBDj8d2aF3cemSZCP" } } ] @@ -527,24 +527,24 @@ Response: { { "cursor": "eyJjIjo2LCJ0Ijo2LCJpIjpmYWxzZX0", "node": { - "digest": "ERSRy9F3o39NCDRWeDVz5AgBGZPmaCdXzzJ6tjd8eY7k", + "digest": "6dR6sJWFBCVAf65zvqJAZBwViUT1PdjmgWmPckqWHtpg", "sender": { "objects": { "edges": [ { - "cursor": "IByRl+xjLSNEC4Q+Y0Few4xDVIcYyUxyZ4oe7WO63+sLBgAAAAAAAAA=" + "cursor": "IB/Q9QzQF/l7BIpKd528Z8tTh9F6eZhLGBmkKbf/tO9TBgAAAAAAAAA=" }, { - "cursor": "IFStyAU4OS4HEIphwSJjArUsneR9JgYjXqrUZixEvrQuBgAAAAAAAAA=" + "cursor": "ICGnNCh4I2/HaGHwgcf6iD7ctXQIY/PunZT9z735xdJsBgAAAAAAAAA=" }, { - "cursor": "IIdbcBHo+WUMzya2grau6zYFD5ZlFX1HQH4pJXAOaRQ7BgAAAAAAAAA=" + "cursor": "IHX+byCmKcy4ITqnqews9sS/OkceFRnc982c7S3ATrNsBgAAAAAAAAA=" }, { - "cursor": "IL4LyEqyfHaJp7x1F47HggXP5K/uTKM7JwRm7NYblBk+BgAAAAAAAAA=" + "cursor": "IITWL6MXHEmVXm4QNxBd8p+ZCNp4uHJaX8C5gh9VzXAtBgAAAAAAAAA=" }, { - "cursor": "IOuXfIr/MFNZLw/UcBw1yb4Asy3a7l9mjzGLhiX0TNM2BgAAAAAAAAA=" + "cursor": "IK/PYAxfnGBPTvQuJjjAlDX1bI4ft+Ho3hD6OQmoySXSBgAAAAAAAAA=" } ] } @@ -558,33 +558,33 @@ Response: { { "cursor": "eyJjIjoxMiwidCI6MiwiaSI6ZmFsc2V9", "node": { - "digest": "3Wu2rNcM39pocoovpHUXZrWtwQXn8ZXAGpwrU7GthLLD", + "digest": "79od1gfpa4bdobeR94ZQ38ea2SbKVrnYo4KiRpUKZKyB", "sender": { "objects": { "edges": [ { - "cursor": "IADSYACaayWIeqSsYbYGygOHm+qGH85EWtI7FGVmu6jlDAAAAAAAAAA=" + "cursor": "IB/Q9QzQF/l7BIpKd528Z8tTh9F6eZhLGBmkKbf/tO9TDAAAAAAAAAA=" }, { - "cursor": "IByRl+xjLSNEC4Q+Y0Few4xDVIcYyUxyZ4oe7WO63+sLDAAAAAAAAAA=" + "cursor": "ICGnNCh4I2/HaGHwgcf6iD7ctXQIY/PunZT9z735xdJsDAAAAAAAAAA=" }, { - "cursor": "IFStyAU4OS4HEIphwSJjArUsneR9JgYjXqrUZixEvrQuDAAAAAAAAAA=" + "cursor": "IHVnj4DBePBVwex0Zi+gGmPcMVtPCdP82UODiOt5gTM3DAAAAAAAAAA=" }, { - "cursor": "IIBhlATYbPevAocg2y+ZqQu/SS+ryiQUhFJdTTaBb9XPDAAAAAAAAAA=" + "cursor": "IHX+byCmKcy4ITqnqews9sS/OkceFRnc982c7S3ATrNsDAAAAAAAAAA=" }, { - "cursor": "IIdbcBHo+WUMzya2grau6zYFD5ZlFX1HQH4pJXAOaRQ7DAAAAAAAAAA=" + "cursor": "IITWL6MXHEmVXm4QNxBd8p+ZCNp4uHJaX8C5gh9VzXAtDAAAAAAAAAA=" }, { - "cursor": "IJFijS2QC5L0mgGDM8x75mv5mMwWRJMk+x9vBZwIoaU9DAAAAAAAAAA=" + "cursor": "IJyG2SKgEvEV9Z8kB4U0JMQv1ohPcJhTqCciCcSGdClVDAAAAAAAAAA=" }, { - "cursor": "IL4LyEqyfHaJp7x1F47HggXP5K/uTKM7JwRm7NYblBk+DAAAAAAAAAA=" + "cursor": "IKhrY2+bvMHD2r1rakSvggO3lKZRHndT25WguCOH4hNRDAAAAAAAAAA=" }, { - "cursor": "IOuXfIr/MFNZLw/UcBw1yb4Asy3a7l9mjzGLhiX0TNM2DAAAAAAAAAA=" + "cursor": "IK/PYAxfnGBPTvQuJjjAlDX1bI4ft+Ho3hD6OQmoySXSDAAAAAAAAAA=" } ] } @@ -594,33 +594,33 @@ Response: { { "cursor": "eyJjIjoxMiwidCI6NCwiaSI6ZmFsc2V9", "node": { - "digest": "5Fx8EKmMoiHb59rVr2ch64EgLyvs9SWhuUHq6x3HAx3T", + "digest": "7qGUBfHDs1CziLgVJBXamBawVtztiyp2sAPdaRWiPNT1", "sender": { "objects": { "edges": [ { - "cursor": "IADSYACaayWIeqSsYbYGygOHm+qGH85EWtI7FGVmu6jlDAAAAAAAAAA=" + "cursor": "IB/Q9QzQF/l7BIpKd528Z8tTh9F6eZhLGBmkKbf/tO9TDAAAAAAAAAA=" }, { - "cursor": "IByRl+xjLSNEC4Q+Y0Few4xDVIcYyUxyZ4oe7WO63+sLDAAAAAAAAAA=" + "cursor": "ICGnNCh4I2/HaGHwgcf6iD7ctXQIY/PunZT9z735xdJsDAAAAAAAAAA=" }, { - "cursor": "IFStyAU4OS4HEIphwSJjArUsneR9JgYjXqrUZixEvrQuDAAAAAAAAAA=" + "cursor": "IHVnj4DBePBVwex0Zi+gGmPcMVtPCdP82UODiOt5gTM3DAAAAAAAAAA=" }, { - "cursor": "IIBhlATYbPevAocg2y+ZqQu/SS+ryiQUhFJdTTaBb9XPDAAAAAAAAAA=" + "cursor": "IHX+byCmKcy4ITqnqews9sS/OkceFRnc982c7S3ATrNsDAAAAAAAAAA=" }, { - "cursor": "IIdbcBHo+WUMzya2grau6zYFD5ZlFX1HQH4pJXAOaRQ7DAAAAAAAAAA=" + "cursor": "IITWL6MXHEmVXm4QNxBd8p+ZCNp4uHJaX8C5gh9VzXAtDAAAAAAAAAA=" }, { - "cursor": "IJFijS2QC5L0mgGDM8x75mv5mMwWRJMk+x9vBZwIoaU9DAAAAAAAAAA=" + "cursor": "IJyG2SKgEvEV9Z8kB4U0JMQv1ohPcJhTqCciCcSGdClVDAAAAAAAAAA=" }, { - "cursor": "IL4LyEqyfHaJp7x1F47HggXP5K/uTKM7JwRm7NYblBk+DAAAAAAAAAA=" + "cursor": "IKhrY2+bvMHD2r1rakSvggO3lKZRHndT25WguCOH4hNRDAAAAAAAAAA=" }, { - "cursor": "IOuXfIr/MFNZLw/UcBw1yb4Asy3a7l9mjzGLhiX0TNM2DAAAAAAAAAA=" + "cursor": "IK/PYAxfnGBPTvQuJjjAlDX1bI4ft+Ho3hD6OQmoySXSDAAAAAAAAAA=" } ] } @@ -630,33 +630,33 @@ Response: { { "cursor": "eyJjIjoxMiwidCI6NSwiaSI6ZmFsc2V9", "node": { - "digest": "DvNBuuqGugb9p76oMb1jLa6MdAv7mT184x69bGKC2rQw", + "digest": "BMAW5GS7peWfXNwjcNKYfRqWDJ5Mb7eY61o1KMcozhFG", "sender": { "objects": { "edges": [ { - "cursor": "IADSYACaayWIeqSsYbYGygOHm+qGH85EWtI7FGVmu6jlDAAAAAAAAAA=" + "cursor": "IB/Q9QzQF/l7BIpKd528Z8tTh9F6eZhLGBmkKbf/tO9TDAAAAAAAAAA=" }, { - "cursor": "IByRl+xjLSNEC4Q+Y0Few4xDVIcYyUxyZ4oe7WO63+sLDAAAAAAAAAA=" + "cursor": "ICGnNCh4I2/HaGHwgcf6iD7ctXQIY/PunZT9z735xdJsDAAAAAAAAAA=" }, { - "cursor": "IFStyAU4OS4HEIphwSJjArUsneR9JgYjXqrUZixEvrQuDAAAAAAAAAA=" + "cursor": "IHVnj4DBePBVwex0Zi+gGmPcMVtPCdP82UODiOt5gTM3DAAAAAAAAAA=" }, { - "cursor": "IIBhlATYbPevAocg2y+ZqQu/SS+ryiQUhFJdTTaBb9XPDAAAAAAAAAA=" + "cursor": "IHX+byCmKcy4ITqnqews9sS/OkceFRnc982c7S3ATrNsDAAAAAAAAAA=" }, { - "cursor": "IIdbcBHo+WUMzya2grau6zYFD5ZlFX1HQH4pJXAOaRQ7DAAAAAAAAAA=" + "cursor": "IITWL6MXHEmVXm4QNxBd8p+ZCNp4uHJaX8C5gh9VzXAtDAAAAAAAAAA=" }, { - "cursor": "IJFijS2QC5L0mgGDM8x75mv5mMwWRJMk+x9vBZwIoaU9DAAAAAAAAAA=" + "cursor": "IJyG2SKgEvEV9Z8kB4U0JMQv1ohPcJhTqCciCcSGdClVDAAAAAAAAAA=" }, { - "cursor": "IL4LyEqyfHaJp7x1F47HggXP5K/uTKM7JwRm7NYblBk+DAAAAAAAAAA=" + "cursor": "IKhrY2+bvMHD2r1rakSvggO3lKZRHndT25WguCOH4hNRDAAAAAAAAAA=" }, { - "cursor": "IOuXfIr/MFNZLw/UcBw1yb4Asy3a7l9mjzGLhiX0TNM2DAAAAAAAAAA=" + "cursor": "IK/PYAxfnGBPTvQuJjjAlDX1bI4ft+Ho3hD6OQmoySXSDAAAAAAAAAA=" } ] } @@ -666,33 +666,33 @@ Response: { { "cursor": "eyJjIjoxMiwidCI6NiwiaSI6ZmFsc2V9", "node": { - "digest": "ERSRy9F3o39NCDRWeDVz5AgBGZPmaCdXzzJ6tjd8eY7k", + "digest": "6dR6sJWFBCVAf65zvqJAZBwViUT1PdjmgWmPckqWHtpg", "sender": { "objects": { "edges": [ { - "cursor": "IADSYACaayWIeqSsYbYGygOHm+qGH85EWtI7FGVmu6jlDAAAAAAAAAA=" + "cursor": "IB/Q9QzQF/l7BIpKd528Z8tTh9F6eZhLGBmkKbf/tO9TDAAAAAAAAAA=" }, { - "cursor": "IByRl+xjLSNEC4Q+Y0Few4xDVIcYyUxyZ4oe7WO63+sLDAAAAAAAAAA=" + "cursor": "ICGnNCh4I2/HaGHwgcf6iD7ctXQIY/PunZT9z735xdJsDAAAAAAAAAA=" }, { - "cursor": "IFStyAU4OS4HEIphwSJjArUsneR9JgYjXqrUZixEvrQuDAAAAAAAAAA=" + "cursor": "IHVnj4DBePBVwex0Zi+gGmPcMVtPCdP82UODiOt5gTM3DAAAAAAAAAA=" }, { - "cursor": "IIBhlATYbPevAocg2y+ZqQu/SS+ryiQUhFJdTTaBb9XPDAAAAAAAAAA=" + "cursor": "IHX+byCmKcy4ITqnqews9sS/OkceFRnc982c7S3ATrNsDAAAAAAAAAA=" }, { - "cursor": "IIdbcBHo+WUMzya2grau6zYFD5ZlFX1HQH4pJXAOaRQ7DAAAAAAAAAA=" + "cursor": "IITWL6MXHEmVXm4QNxBd8p+ZCNp4uHJaX8C5gh9VzXAtDAAAAAAAAAA=" }, { - "cursor": "IJFijS2QC5L0mgGDM8x75mv5mMwWRJMk+x9vBZwIoaU9DAAAAAAAAAA=" + "cursor": "IJyG2SKgEvEV9Z8kB4U0JMQv1ohPcJhTqCciCcSGdClVDAAAAAAAAAA=" }, { - "cursor": "IL4LyEqyfHaJp7x1F47HggXP5K/uTKM7JwRm7NYblBk+DAAAAAAAAAA=" + "cursor": "IKhrY2+bvMHD2r1rakSvggO3lKZRHndT25WguCOH4hNRDAAAAAAAAAA=" }, { - "cursor": "IOuXfIr/MFNZLw/UcBw1yb4Asy3a7l9mjzGLhiX0TNM2DAAAAAAAAAA=" + "cursor": "IK/PYAxfnGBPTvQuJjjAlDX1bI4ft+Ho3hD6OQmoySXSDAAAAAAAAAA=" } ] } @@ -702,33 +702,33 @@ Response: { { "cursor": "eyJjIjoxMiwidCI6OCwiaSI6ZmFsc2V9", "node": { - "digest": "2uLirA5sxREeS1UHEKCJWeoMv2R1MKCUiiep9Q6s7WA6", + "digest": "5mUu9bxNaotcEsssawXpQWZ5Rd2RkjbssbZHy4YqP6jj", "sender": { "objects": { "edges": [ { - "cursor": "IADSYACaayWIeqSsYbYGygOHm+qGH85EWtI7FGVmu6jlDAAAAAAAAAA=" + "cursor": "IB/Q9QzQF/l7BIpKd528Z8tTh9F6eZhLGBmkKbf/tO9TDAAAAAAAAAA=" }, { - "cursor": "IByRl+xjLSNEC4Q+Y0Few4xDVIcYyUxyZ4oe7WO63+sLDAAAAAAAAAA=" + "cursor": "ICGnNCh4I2/HaGHwgcf6iD7ctXQIY/PunZT9z735xdJsDAAAAAAAAAA=" }, { - "cursor": "IFStyAU4OS4HEIphwSJjArUsneR9JgYjXqrUZixEvrQuDAAAAAAAAAA=" + "cursor": "IHVnj4DBePBVwex0Zi+gGmPcMVtPCdP82UODiOt5gTM3DAAAAAAAAAA=" }, { - "cursor": "IIBhlATYbPevAocg2y+ZqQu/SS+ryiQUhFJdTTaBb9XPDAAAAAAAAAA=" + "cursor": "IHX+byCmKcy4ITqnqews9sS/OkceFRnc982c7S3ATrNsDAAAAAAAAAA=" }, { - "cursor": "IIdbcBHo+WUMzya2grau6zYFD5ZlFX1HQH4pJXAOaRQ7DAAAAAAAAAA=" + "cursor": "IITWL6MXHEmVXm4QNxBd8p+ZCNp4uHJaX8C5gh9VzXAtDAAAAAAAAAA=" }, { - "cursor": "IJFijS2QC5L0mgGDM8x75mv5mMwWRJMk+x9vBZwIoaU9DAAAAAAAAAA=" + "cursor": "IJyG2SKgEvEV9Z8kB4U0JMQv1ohPcJhTqCciCcSGdClVDAAAAAAAAAA=" }, { - "cursor": "IL4LyEqyfHaJp7x1F47HggXP5K/uTKM7JwRm7NYblBk+DAAAAAAAAAA=" + "cursor": "IKhrY2+bvMHD2r1rakSvggO3lKZRHndT25WguCOH4hNRDAAAAAAAAAA=" }, { - "cursor": "IOuXfIr/MFNZLw/UcBw1yb4Asy3a7l9mjzGLhiX0TNM2DAAAAAAAAAA=" + "cursor": "IK/PYAxfnGBPTvQuJjjAlDX1bI4ft+Ho3hD6OQmoySXSDAAAAAAAAAA=" } ] } @@ -738,33 +738,33 @@ Response: { { "cursor": "eyJjIjoxMiwidCI6OSwiaSI6ZmFsc2V9", "node": { - "digest": "4HgxdMoiQdZbLrd7ycQ3csPtccNPvr9BZW67ykV7NRk6", + "digest": "26L1PsnhdXmQHEgRiqw9WTMmFZy8CJUjta7yGuuvH7DD", "sender": { "objects": { "edges": [ { - "cursor": "IADSYACaayWIeqSsYbYGygOHm+qGH85EWtI7FGVmu6jlDAAAAAAAAAA=" + "cursor": "IB/Q9QzQF/l7BIpKd528Z8tTh9F6eZhLGBmkKbf/tO9TDAAAAAAAAAA=" }, { - "cursor": "IByRl+xjLSNEC4Q+Y0Few4xDVIcYyUxyZ4oe7WO63+sLDAAAAAAAAAA=" + "cursor": "ICGnNCh4I2/HaGHwgcf6iD7ctXQIY/PunZT9z735xdJsDAAAAAAAAAA=" }, { - "cursor": "IFStyAU4OS4HEIphwSJjArUsneR9JgYjXqrUZixEvrQuDAAAAAAAAAA=" + "cursor": "IHVnj4DBePBVwex0Zi+gGmPcMVtPCdP82UODiOt5gTM3DAAAAAAAAAA=" }, { - "cursor": "IIBhlATYbPevAocg2y+ZqQu/SS+ryiQUhFJdTTaBb9XPDAAAAAAAAAA=" + "cursor": "IHX+byCmKcy4ITqnqews9sS/OkceFRnc982c7S3ATrNsDAAAAAAAAAA=" }, { - "cursor": "IIdbcBHo+WUMzya2grau6zYFD5ZlFX1HQH4pJXAOaRQ7DAAAAAAAAAA=" + "cursor": "IITWL6MXHEmVXm4QNxBd8p+ZCNp4uHJaX8C5gh9VzXAtDAAAAAAAAAA=" }, { - "cursor": "IJFijS2QC5L0mgGDM8x75mv5mMwWRJMk+x9vBZwIoaU9DAAAAAAAAAA=" + "cursor": "IJyG2SKgEvEV9Z8kB4U0JMQv1ohPcJhTqCciCcSGdClVDAAAAAAAAAA=" }, { - "cursor": "IL4LyEqyfHaJp7x1F47HggXP5K/uTKM7JwRm7NYblBk+DAAAAAAAAAA=" + "cursor": "IKhrY2+bvMHD2r1rakSvggO3lKZRHndT25WguCOH4hNRDAAAAAAAAAA=" }, { - "cursor": "IOuXfIr/MFNZLw/UcBw1yb4Asy3a7l9mjzGLhiX0TNM2DAAAAAAAAAA=" + "cursor": "IK/PYAxfnGBPTvQuJjjAlDX1bI4ft+Ho3hD6OQmoySXSDAAAAAAAAAA=" } ] } @@ -774,33 +774,33 @@ Response: { { "cursor": "eyJjIjoxMiwidCI6MTAsImkiOmZhbHNlfQ", "node": { - "digest": "d9yohmp3svrBRKZjbfv7Gn5TbCrmspbqis2wy76ES1M", + "digest": "9Rztd6zgt6r1kZ5hUPALhi8K2ZXBBDj8d2aF3cemSZCP", "sender": { "objects": { "edges": [ { - "cursor": "IADSYACaayWIeqSsYbYGygOHm+qGH85EWtI7FGVmu6jlDAAAAAAAAAA=" + "cursor": "IB/Q9QzQF/l7BIpKd528Z8tTh9F6eZhLGBmkKbf/tO9TDAAAAAAAAAA=" }, { - "cursor": "IByRl+xjLSNEC4Q+Y0Few4xDVIcYyUxyZ4oe7WO63+sLDAAAAAAAAAA=" + "cursor": "ICGnNCh4I2/HaGHwgcf6iD7ctXQIY/PunZT9z735xdJsDAAAAAAAAAA=" }, { - "cursor": "IFStyAU4OS4HEIphwSJjArUsneR9JgYjXqrUZixEvrQuDAAAAAAAAAA=" + "cursor": "IHVnj4DBePBVwex0Zi+gGmPcMVtPCdP82UODiOt5gTM3DAAAAAAAAAA=" }, { - "cursor": "IIBhlATYbPevAocg2y+ZqQu/SS+ryiQUhFJdTTaBb9XPDAAAAAAAAAA=" + "cursor": "IHX+byCmKcy4ITqnqews9sS/OkceFRnc982c7S3ATrNsDAAAAAAAAAA=" }, { - "cursor": "IIdbcBHo+WUMzya2grau6zYFD5ZlFX1HQH4pJXAOaRQ7DAAAAAAAAAA=" + "cursor": "IITWL6MXHEmVXm4QNxBd8p+ZCNp4uHJaX8C5gh9VzXAtDAAAAAAAAAA=" }, { - "cursor": "IJFijS2QC5L0mgGDM8x75mv5mMwWRJMk+x9vBZwIoaU9DAAAAAAAAAA=" + "cursor": "IJyG2SKgEvEV9Z8kB4U0JMQv1ohPcJhTqCciCcSGdClVDAAAAAAAAAA=" }, { - "cursor": "IL4LyEqyfHaJp7x1F47HggXP5K/uTKM7JwRm7NYblBk+DAAAAAAAAAA=" + "cursor": "IKhrY2+bvMHD2r1rakSvggO3lKZRHndT25WguCOH4hNRDAAAAAAAAAA=" }, { - "cursor": "IOuXfIr/MFNZLw/UcBw1yb4Asy3a7l9mjzGLhiX0TNM2DAAAAAAAAAA=" + "cursor": "IK/PYAxfnGBPTvQuJjjAlDX1bI4ft+Ho3hD6OQmoySXSDAAAAAAAAAA=" } ] } diff --git a/crates/iota-graphql-e2e-tests/tests/consistency/object_at_version.exp b/crates/iota-graphql-e2e-tests/tests/consistency/object_at_version.exp index 9d554e7d4f5..74fdc1870f4 100644 --- a/crates/iota-graphql-e2e-tests/tests/consistency/object_at_version.exp +++ b/crates/iota-graphql-e2e-tests/tests/consistency/object_at_version.exp @@ -29,7 +29,7 @@ Response: { "asMoveObject": { "contents": { "json": { - "id": "0x38a4c99d150ee4023f4ecd569c9c49c86c45a5d58bf9dda1355497eacacb7850", + "id": "0x8c1a40e2608492f92365d5bd1edc6388bcf2769244597f1e19caa1b0a00513da", "value": "0" } } @@ -57,7 +57,7 @@ Response: { "asMoveObject": { "contents": { "json": { - "id": "0x38a4c99d150ee4023f4ecd569c9c49c86c45a5d58bf9dda1355497eacacb7850", + "id": "0x8c1a40e2608492f92365d5bd1edc6388bcf2769244597f1e19caa1b0a00513da", "value": "1" } } @@ -69,7 +69,7 @@ Response: { "asMoveObject": { "contents": { "json": { - "id": "0x38a4c99d150ee4023f4ecd569c9c49c86c45a5d58bf9dda1355497eacacb7850", + "id": "0x8c1a40e2608492f92365d5bd1edc6388bcf2769244597f1e19caa1b0a00513da", "value": "0" } } @@ -104,7 +104,7 @@ Response: { "asMoveObject": { "contents": { "json": { - "id": "0x38a4c99d150ee4023f4ecd569c9c49c86c45a5d58bf9dda1355497eacacb7850", + "id": "0x8c1a40e2608492f92365d5bd1edc6388bcf2769244597f1e19caa1b0a00513da", "value": "1" } } @@ -134,7 +134,7 @@ Response: { "asMoveObject": { "contents": { "json": { - "id": "0x38a4c99d150ee4023f4ecd569c9c49c86c45a5d58bf9dda1355497eacacb7850", + "id": "0x8c1a40e2608492f92365d5bd1edc6388bcf2769244597f1e19caa1b0a00513da", "value": "1" } } @@ -151,7 +151,7 @@ Response: { "asMoveObject": { "contents": { "json": { - "id": "0x38a4c99d150ee4023f4ecd569c9c49c86c45a5d58bf9dda1355497eacacb7850", + "id": "0x8c1a40e2608492f92365d5bd1edc6388bcf2769244597f1e19caa1b0a00513da", "value": "0" } } @@ -205,7 +205,7 @@ Response: { "asMoveObject": { "contents": { "json": { - "id": "0x38a4c99d150ee4023f4ecd569c9c49c86c45a5d58bf9dda1355497eacacb7850", + "id": "0x8c1a40e2608492f92365d5bd1edc6388bcf2769244597f1e19caa1b0a00513da", "value": "1" } } @@ -222,7 +222,7 @@ Response: { "asMoveObject": { "contents": { "json": { - "id": "0x38a4c99d150ee4023f4ecd569c9c49c86c45a5d58bf9dda1355497eacacb7850", + "id": "0x8c1a40e2608492f92365d5bd1edc6388bcf2769244597f1e19caa1b0a00513da", "value": "0" } } diff --git a/crates/iota-graphql-e2e-tests/tests/consistency/objects_pagination.exp b/crates/iota-graphql-e2e-tests/tests/consistency/objects_pagination.exp index c88584d2c19..8d1ce341b94 100644 --- a/crates/iota-graphql-e2e-tests/tests/consistency/objects_pagination.exp +++ b/crates/iota-graphql-e2e-tests/tests/consistency/objects_pagination.exp @@ -31,24 +31,26 @@ Response: { "data": { "one_of_these_will_yield_an_object": { "objects": { - "nodes": [ - { - "version": 4, + "nodes": [] + } + }, + "if_the_other_does_not": { + "nodes": [ + { + "version": 3, + "asMoveObject": { "contents": { "type": { - "repr": "0xa9cbee3dea1fbcfbc892ff3689f58dc1620558f5f31f6cd3e2b75010e2df732c::M1::Object" + "repr": "0x2ce2fe50016683a5ad096b8c1e8ea6c49de008c19cee60f38a4d51c92a475e6c::M1::Object" }, "json": { - "id": "0x4c94d3aa104e529fdf2ce54b0813332b0b587d5b36d04ec87a9776db93ae093a", - "value": "1" + "id": "0x5c76eac8095495f0bcb5569dd535172e4f4fdf76fedd97d97ebe3a332811f88a", + "value": "0" } } } - ] - } - }, - "if_the_other_does_not": { - "nodes": [] + } + ] } } } @@ -75,24 +77,26 @@ Response: { "data": { "paginating_on_checkpoint_1": { "objects": { - "nodes": [ - { - "version": 4, + "nodes": [] + } + }, + "should_not_have_more_than_one_result": { + "nodes": [ + { + "version": 3, + "asMoveObject": { "contents": { "type": { - "repr": "0xa9cbee3dea1fbcfbc892ff3689f58dc1620558f5f31f6cd3e2b75010e2df732c::M1::Object" + "repr": "0x2ce2fe50016683a5ad096b8c1e8ea6c49de008c19cee60f38a4d51c92a475e6c::M1::Object" }, "json": { - "id": "0x4c94d3aa104e529fdf2ce54b0813332b0b587d5b36d04ec87a9776db93ae093a", - "value": "1" + "id": "0x5c76eac8095495f0bcb5569dd535172e4f4fdf76fedd97d97ebe3a332811f88a", + "value": "0" } } } - ] - } - }, - "should_not_have_more_than_one_result": { - "nodes": [] + } + ] } } } @@ -105,50 +109,50 @@ Response: { "objects": { "nodes": [ { - "version": 6, + "version": 5, "contents": { "type": { - "repr": "0xa9cbee3dea1fbcfbc892ff3689f58dc1620558f5f31f6cd3e2b75010e2df732c::M1::Object" + "repr": "0x2ce2fe50016683a5ad096b8c1e8ea6c49de008c19cee60f38a4d51c92a475e6c::M1::Object" }, "json": { - "id": "0x0276236f1293f0797f2a9d85f4385dc166206d14963eb528a8f0cb82171e4a1c", - "value": "3" + "id": "0x23f0b02cd7c428390e14aac34b5677662593d02bd26f29097eee0885bd32e409", + "value": "2" } } }, { - "version": 3, + "version": 4, "contents": { "type": { - "repr": "0xa9cbee3dea1fbcfbc892ff3689f58dc1620558f5f31f6cd3e2b75010e2df732c::M1::Object" + "repr": "0x2ce2fe50016683a5ad096b8c1e8ea6c49de008c19cee60f38a4d51c92a475e6c::M1::Object" }, "json": { - "id": "0x239663104e1d8db2011e6eb4df325556361bbf73414d25d4545491d30b351666", - "value": "0" + "id": "0x459eefbe82c1f2eceaa293085408b3959db89b88aef5ac8359e3f637f9e20315", + "value": "1" } } }, { - "version": 5, + "version": 3, "contents": { "type": { - "repr": "0xa9cbee3dea1fbcfbc892ff3689f58dc1620558f5f31f6cd3e2b75010e2df732c::M1::Object" + "repr": "0x2ce2fe50016683a5ad096b8c1e8ea6c49de008c19cee60f38a4d51c92a475e6c::M1::Object" }, "json": { - "id": "0x36f05b1d8a31406630118071eb1742dfc0c6283062b254d8e8e64d24320fd382", - "value": "2" + "id": "0x5c76eac8095495f0bcb5569dd535172e4f4fdf76fedd97d97ebe3a332811f88a", + "value": "0" } } }, { - "version": 4, + "version": 6, "contents": { "type": { - "repr": "0xa9cbee3dea1fbcfbc892ff3689f58dc1620558f5f31f6cd3e2b75010e2df732c::M1::Object" + "repr": "0x2ce2fe50016683a5ad096b8c1e8ea6c49de008c19cee60f38a4d51c92a475e6c::M1::Object" }, "json": { - "id": "0x4c94d3aa104e529fdf2ce54b0813332b0b587d5b36d04ec87a9776db93ae093a", - "value": "1" + "id": "0x9844d52d8e6114c534d1c6f4ce72aa53e3b82c061765b50dbda7c0d1f403c604", + "value": "3" } } } @@ -166,50 +170,50 @@ Response: { "objects": { "nodes": [ { - "version": 6, + "version": 5, "contents": { "type": { - "repr": "0xa9cbee3dea1fbcfbc892ff3689f58dc1620558f5f31f6cd3e2b75010e2df732c::M1::Object" + "repr": "0x2ce2fe50016683a5ad096b8c1e8ea6c49de008c19cee60f38a4d51c92a475e6c::M1::Object" }, "json": { - "id": "0x0276236f1293f0797f2a9d85f4385dc166206d14963eb528a8f0cb82171e4a1c", - "value": "3" + "id": "0x23f0b02cd7c428390e14aac34b5677662593d02bd26f29097eee0885bd32e409", + "value": "2" } } }, { - "version": 3, + "version": 4, "contents": { "type": { - "repr": "0xa9cbee3dea1fbcfbc892ff3689f58dc1620558f5f31f6cd3e2b75010e2df732c::M1::Object" + "repr": "0x2ce2fe50016683a5ad096b8c1e8ea6c49de008c19cee60f38a4d51c92a475e6c::M1::Object" }, "json": { - "id": "0x239663104e1d8db2011e6eb4df325556361bbf73414d25d4545491d30b351666", - "value": "0" + "id": "0x459eefbe82c1f2eceaa293085408b3959db89b88aef5ac8359e3f637f9e20315", + "value": "1" } } }, { - "version": 5, + "version": 3, "contents": { "type": { - "repr": "0xa9cbee3dea1fbcfbc892ff3689f58dc1620558f5f31f6cd3e2b75010e2df732c::M1::Object" + "repr": "0x2ce2fe50016683a5ad096b8c1e8ea6c49de008c19cee60f38a4d51c92a475e6c::M1::Object" }, "json": { - "id": "0x36f05b1d8a31406630118071eb1742dfc0c6283062b254d8e8e64d24320fd382", - "value": "2" + "id": "0x5c76eac8095495f0bcb5569dd535172e4f4fdf76fedd97d97ebe3a332811f88a", + "value": "0" } } }, { - "version": 4, + "version": 6, "contents": { "type": { - "repr": "0xa9cbee3dea1fbcfbc892ff3689f58dc1620558f5f31f6cd3e2b75010e2df732c::M1::Object" + "repr": "0x2ce2fe50016683a5ad096b8c1e8ea6c49de008c19cee60f38a4d51c92a475e6c::M1::Object" }, "json": { - "id": "0x4c94d3aa104e529fdf2ce54b0813332b0b587d5b36d04ec87a9776db93ae093a", - "value": "1" + "id": "0x9844d52d8e6114c534d1c6f4ce72aa53e3b82c061765b50dbda7c0d1f403c604", + "value": "3" } } } @@ -240,10 +244,10 @@ Response: { "version": 4, "contents": { "type": { - "repr": "0xa9cbee3dea1fbcfbc892ff3689f58dc1620558f5f31f6cd3e2b75010e2df732c::M1::Object" + "repr": "0x2ce2fe50016683a5ad096b8c1e8ea6c49de008c19cee60f38a4d51c92a475e6c::M1::Object" }, "json": { - "id": "0x4c94d3aa104e529fdf2ce54b0813332b0b587d5b36d04ec87a9776db93ae093a", + "id": "0x459eefbe82c1f2eceaa293085408b3959db89b88aef5ac8359e3f637f9e20315", "value": "1" } }, @@ -252,64 +256,64 @@ Response: { "objects": { "nodes": [ { - "version": 6, + "version": 1, "contents": { "type": { - "repr": "0xa9cbee3dea1fbcfbc892ff3689f58dc1620558f5f31f6cd3e2b75010e2df732c::M1::Object" + "repr": "0x0000000000000000000000000000000000000000000000000000000000000002::coin::Coin<0x0000000000000000000000000000000000000000000000000000000000000002::iota::IOTA>" }, "json": { - "id": "0x0276236f1293f0797f2a9d85f4385dc166206d14963eb528a8f0cb82171e4a1c", - "value": "3" + "id": "0x1fd0f50cd017f97b048a4a779dbc67cb5387d17a79984b1819a429b7ffb4ef53", + "balance": { + "value": "300000000000000" + } } } }, { - "version": 3, + "version": 5, "contents": { "type": { - "repr": "0xa9cbee3dea1fbcfbc892ff3689f58dc1620558f5f31f6cd3e2b75010e2df732c::M1::Object" + "repr": "0x2ce2fe50016683a5ad096b8c1e8ea6c49de008c19cee60f38a4d51c92a475e6c::M1::Object" }, "json": { - "id": "0x239663104e1d8db2011e6eb4df325556361bbf73414d25d4545491d30b351666", - "value": "0" + "id": "0x23f0b02cd7c428390e14aac34b5677662593d02bd26f29097eee0885bd32e409", + "value": "2" } } }, { - "version": 5, + "version": 4, "contents": { "type": { - "repr": "0xa9cbee3dea1fbcfbc892ff3689f58dc1620558f5f31f6cd3e2b75010e2df732c::M1::Object" + "repr": "0x2ce2fe50016683a5ad096b8c1e8ea6c49de008c19cee60f38a4d51c92a475e6c::M1::Object" }, "json": { - "id": "0x36f05b1d8a31406630118071eb1742dfc0c6283062b254d8e8e64d24320fd382", - "value": "2" + "id": "0x459eefbe82c1f2eceaa293085408b3959db89b88aef5ac8359e3f637f9e20315", + "value": "1" } } }, { - "version": 4, + "version": 3, "contents": { "type": { - "repr": "0xa9cbee3dea1fbcfbc892ff3689f58dc1620558f5f31f6cd3e2b75010e2df732c::M1::Object" + "repr": "0x2ce2fe50016683a5ad096b8c1e8ea6c49de008c19cee60f38a4d51c92a475e6c::M1::Object" }, "json": { - "id": "0x4c94d3aa104e529fdf2ce54b0813332b0b587d5b36d04ec87a9776db93ae093a", - "value": "1" + "id": "0x5c76eac8095495f0bcb5569dd535172e4f4fdf76fedd97d97ebe3a332811f88a", + "value": "0" } } }, { - "version": 1, + "version": 6, "contents": { "type": { - "repr": "0x0000000000000000000000000000000000000000000000000000000000000002::coin::Coin<0x0000000000000000000000000000000000000000000000000000000000000002::iota::IOTA>" + "repr": "0x2ce2fe50016683a5ad096b8c1e8ea6c49de008c19cee60f38a4d51c92a475e6c::M1::Object" }, "json": { - "id": "0x875b7011e8f9650ccf26b682b6aeeb36050f9665157d47407e2925700e69143b", - "balance": { - "value": "300000000000000" - } + "id": "0x9844d52d8e6114c534d1c6f4ce72aa53e3b82c061765b50dbda7c0d1f403c604", + "value": "3" } } } @@ -317,87 +321,81 @@ Response: { } } } - } - ] - } - }, - "before_obj_6_0_at_checkpoint_2": { - "nodes": [ - { - "version": 6, - "asMoveObject": { + }, + { + "version": 3, "contents": { "type": { - "repr": "0xa9cbee3dea1fbcfbc892ff3689f58dc1620558f5f31f6cd3e2b75010e2df732c::M1::Object" + "repr": "0x2ce2fe50016683a5ad096b8c1e8ea6c49de008c19cee60f38a4d51c92a475e6c::M1::Object" }, "json": { - "id": "0x0276236f1293f0797f2a9d85f4385dc166206d14963eb528a8f0cb82171e4a1c", - "value": "3" + "id": "0x5c76eac8095495f0bcb5569dd535172e4f4fdf76fedd97d97ebe3a332811f88a", + "value": "0" } }, - "note_that_owner_result_should_reflect_latest_state": { + "owner_at_latest_state_has_iota_only": { "owner": { "objects": { "nodes": [ { - "version": 6, + "version": 1, "contents": { "type": { - "repr": "0xa9cbee3dea1fbcfbc892ff3689f58dc1620558f5f31f6cd3e2b75010e2df732c::M1::Object" + "repr": "0x0000000000000000000000000000000000000000000000000000000000000002::coin::Coin<0x0000000000000000000000000000000000000000000000000000000000000002::iota::IOTA>" }, "json": { - "id": "0x0276236f1293f0797f2a9d85f4385dc166206d14963eb528a8f0cb82171e4a1c", - "value": "3" + "id": "0x1fd0f50cd017f97b048a4a779dbc67cb5387d17a79984b1819a429b7ffb4ef53", + "balance": { + "value": "300000000000000" + } } } }, { - "version": 3, + "version": 5, "contents": { "type": { - "repr": "0xa9cbee3dea1fbcfbc892ff3689f58dc1620558f5f31f6cd3e2b75010e2df732c::M1::Object" + "repr": "0x2ce2fe50016683a5ad096b8c1e8ea6c49de008c19cee60f38a4d51c92a475e6c::M1::Object" }, "json": { - "id": "0x239663104e1d8db2011e6eb4df325556361bbf73414d25d4545491d30b351666", - "value": "0" + "id": "0x23f0b02cd7c428390e14aac34b5677662593d02bd26f29097eee0885bd32e409", + "value": "2" } } }, { - "version": 5, + "version": 4, "contents": { "type": { - "repr": "0xa9cbee3dea1fbcfbc892ff3689f58dc1620558f5f31f6cd3e2b75010e2df732c::M1::Object" + "repr": "0x2ce2fe50016683a5ad096b8c1e8ea6c49de008c19cee60f38a4d51c92a475e6c::M1::Object" }, "json": { - "id": "0x36f05b1d8a31406630118071eb1742dfc0c6283062b254d8e8e64d24320fd382", - "value": "2" + "id": "0x459eefbe82c1f2eceaa293085408b3959db89b88aef5ac8359e3f637f9e20315", + "value": "1" } } }, { - "version": 4, + "version": 3, "contents": { "type": { - "repr": "0xa9cbee3dea1fbcfbc892ff3689f58dc1620558f5f31f6cd3e2b75010e2df732c::M1::Object" + "repr": "0x2ce2fe50016683a5ad096b8c1e8ea6c49de008c19cee60f38a4d51c92a475e6c::M1::Object" }, "json": { - "id": "0x4c94d3aa104e529fdf2ce54b0813332b0b587d5b36d04ec87a9776db93ae093a", - "value": "1" + "id": "0x5c76eac8095495f0bcb5569dd535172e4f4fdf76fedd97d97ebe3a332811f88a", + "value": "0" } } }, { - "version": 1, + "version": 6, "contents": { "type": { - "repr": "0x0000000000000000000000000000000000000000000000000000000000000002::coin::Coin<0x0000000000000000000000000000000000000000000000000000000000000002::iota::IOTA>" + "repr": "0x2ce2fe50016683a5ad096b8c1e8ea6c49de008c19cee60f38a4d51c92a475e6c::M1::Object" }, "json": { - "id": "0x875b7011e8f9650ccf26b682b6aeeb36050f9665157d47407e2925700e69143b", - "balance": { - "value": "300000000000000" - } + "id": "0x9844d52d8e6114c534d1c6f4ce72aa53e3b82c061765b50dbda7c0d1f403c604", + "value": "3" } } } @@ -405,83 +403,81 @@ Response: { } } } - } - }, - { - "version": 3, - "asMoveObject": { + }, + { + "version": 6, "contents": { "type": { - "repr": "0xa9cbee3dea1fbcfbc892ff3689f58dc1620558f5f31f6cd3e2b75010e2df732c::M1::Object" + "repr": "0x2ce2fe50016683a5ad096b8c1e8ea6c49de008c19cee60f38a4d51c92a475e6c::M1::Object" }, "json": { - "id": "0x239663104e1d8db2011e6eb4df325556361bbf73414d25d4545491d30b351666", - "value": "0" + "id": "0x9844d52d8e6114c534d1c6f4ce72aa53e3b82c061765b50dbda7c0d1f403c604", + "value": "3" } }, - "note_that_owner_result_should_reflect_latest_state": { + "owner_at_latest_state_has_iota_only": { "owner": { "objects": { "nodes": [ { - "version": 6, + "version": 1, "contents": { "type": { - "repr": "0xa9cbee3dea1fbcfbc892ff3689f58dc1620558f5f31f6cd3e2b75010e2df732c::M1::Object" + "repr": "0x0000000000000000000000000000000000000000000000000000000000000002::coin::Coin<0x0000000000000000000000000000000000000000000000000000000000000002::iota::IOTA>" }, "json": { - "id": "0x0276236f1293f0797f2a9d85f4385dc166206d14963eb528a8f0cb82171e4a1c", - "value": "3" + "id": "0x1fd0f50cd017f97b048a4a779dbc67cb5387d17a79984b1819a429b7ffb4ef53", + "balance": { + "value": "300000000000000" + } } } }, { - "version": 3, + "version": 5, "contents": { "type": { - "repr": "0xa9cbee3dea1fbcfbc892ff3689f58dc1620558f5f31f6cd3e2b75010e2df732c::M1::Object" + "repr": "0x2ce2fe50016683a5ad096b8c1e8ea6c49de008c19cee60f38a4d51c92a475e6c::M1::Object" }, "json": { - "id": "0x239663104e1d8db2011e6eb4df325556361bbf73414d25d4545491d30b351666", - "value": "0" + "id": "0x23f0b02cd7c428390e14aac34b5677662593d02bd26f29097eee0885bd32e409", + "value": "2" } } }, { - "version": 5, + "version": 4, "contents": { "type": { - "repr": "0xa9cbee3dea1fbcfbc892ff3689f58dc1620558f5f31f6cd3e2b75010e2df732c::M1::Object" + "repr": "0x2ce2fe50016683a5ad096b8c1e8ea6c49de008c19cee60f38a4d51c92a475e6c::M1::Object" }, "json": { - "id": "0x36f05b1d8a31406630118071eb1742dfc0c6283062b254d8e8e64d24320fd382", - "value": "2" + "id": "0x459eefbe82c1f2eceaa293085408b3959db89b88aef5ac8359e3f637f9e20315", + "value": "1" } } }, { - "version": 4, + "version": 3, "contents": { "type": { - "repr": "0xa9cbee3dea1fbcfbc892ff3689f58dc1620558f5f31f6cd3e2b75010e2df732c::M1::Object" + "repr": "0x2ce2fe50016683a5ad096b8c1e8ea6c49de008c19cee60f38a4d51c92a475e6c::M1::Object" }, "json": { - "id": "0x4c94d3aa104e529fdf2ce54b0813332b0b587d5b36d04ec87a9776db93ae093a", - "value": "1" + "id": "0x5c76eac8095495f0bcb5569dd535172e4f4fdf76fedd97d97ebe3a332811f88a", + "value": "0" } } }, { - "version": 1, + "version": 6, "contents": { "type": { - "repr": "0x0000000000000000000000000000000000000000000000000000000000000002::coin::Coin<0x0000000000000000000000000000000000000000000000000000000000000002::iota::IOTA>" + "repr": "0x2ce2fe50016683a5ad096b8c1e8ea6c49de008c19cee60f38a4d51c92a475e6c::M1::Object" }, "json": { - "id": "0x875b7011e8f9650ccf26b682b6aeeb36050f9665157d47407e2925700e69143b", - "balance": { - "value": "300000000000000" - } + "id": "0x9844d52d8e6114c534d1c6f4ce72aa53e3b82c061765b50dbda7c0d1f403c604", + "value": "3" } } } @@ -490,8 +486,11 @@ Response: { } } } - } - ] + ] + } + }, + "before_obj_6_0_at_checkpoint_2": { + "nodes": [] } } } @@ -546,11 +545,11 @@ Response: { "version": 7, "contents": { "type": { - "repr": "0xa9cbee3dea1fbcfbc892ff3689f58dc1620558f5f31f6cd3e2b75010e2df732c::M1::Object" + "repr": "0x2ce2fe50016683a5ad096b8c1e8ea6c49de008c19cee60f38a4d51c92a475e6c::M1::Object" }, "json": { - "id": "0x0276236f1293f0797f2a9d85f4385dc166206d14963eb528a8f0cb82171e4a1c", - "value": "3" + "id": "0x23f0b02cd7c428390e14aac34b5677662593d02bd26f29097eee0885bd32e409", + "value": "2" } } }, @@ -558,11 +557,11 @@ Response: { "version": 7, "contents": { "type": { - "repr": "0xa9cbee3dea1fbcfbc892ff3689f58dc1620558f5f31f6cd3e2b75010e2df732c::M1::Object" + "repr": "0x2ce2fe50016683a5ad096b8c1e8ea6c49de008c19cee60f38a4d51c92a475e6c::M1::Object" }, "json": { - "id": "0x239663104e1d8db2011e6eb4df325556361bbf73414d25d4545491d30b351666", - "value": "0" + "id": "0x459eefbe82c1f2eceaa293085408b3959db89b88aef5ac8359e3f637f9e20315", + "value": "1" } } }, @@ -570,11 +569,11 @@ Response: { "version": 7, "contents": { "type": { - "repr": "0xa9cbee3dea1fbcfbc892ff3689f58dc1620558f5f31f6cd3e2b75010e2df732c::M1::Object" + "repr": "0x2ce2fe50016683a5ad096b8c1e8ea6c49de008c19cee60f38a4d51c92a475e6c::M1::Object" }, "json": { - "id": "0x36f05b1d8a31406630118071eb1742dfc0c6283062b254d8e8e64d24320fd382", - "value": "2" + "id": "0x5c76eac8095495f0bcb5569dd535172e4f4fdf76fedd97d97ebe3a332811f88a", + "value": "0" } } }, @@ -582,11 +581,11 @@ Response: { "version": 7, "contents": { "type": { - "repr": "0xa9cbee3dea1fbcfbc892ff3689f58dc1620558f5f31f6cd3e2b75010e2df732c::M1::Object" + "repr": "0x2ce2fe50016683a5ad096b8c1e8ea6c49de008c19cee60f38a4d51c92a475e6c::M1::Object" }, "json": { - "id": "0x4c94d3aa104e529fdf2ce54b0813332b0b587d5b36d04ec87a9776db93ae093a", - "value": "1" + "id": "0x9844d52d8e6114c534d1c6f4ce72aa53e3b82c061765b50dbda7c0d1f403c604", + "value": "3" } } } @@ -604,50 +603,50 @@ Response: { "objects": { "nodes": [ { - "version": 6, + "version": 5, "contents": { "type": { - "repr": "0xa9cbee3dea1fbcfbc892ff3689f58dc1620558f5f31f6cd3e2b75010e2df732c::M1::Object" + "repr": "0x2ce2fe50016683a5ad096b8c1e8ea6c49de008c19cee60f38a4d51c92a475e6c::M1::Object" }, "json": { - "id": "0x0276236f1293f0797f2a9d85f4385dc166206d14963eb528a8f0cb82171e4a1c", - "value": "3" + "id": "0x23f0b02cd7c428390e14aac34b5677662593d02bd26f29097eee0885bd32e409", + "value": "2" } } }, { - "version": 3, + "version": 4, "contents": { "type": { - "repr": "0xa9cbee3dea1fbcfbc892ff3689f58dc1620558f5f31f6cd3e2b75010e2df732c::M1::Object" + "repr": "0x2ce2fe50016683a5ad096b8c1e8ea6c49de008c19cee60f38a4d51c92a475e6c::M1::Object" }, "json": { - "id": "0x239663104e1d8db2011e6eb4df325556361bbf73414d25d4545491d30b351666", - "value": "0" + "id": "0x459eefbe82c1f2eceaa293085408b3959db89b88aef5ac8359e3f637f9e20315", + "value": "1" } } }, { - "version": 5, + "version": 3, "contents": { "type": { - "repr": "0xa9cbee3dea1fbcfbc892ff3689f58dc1620558f5f31f6cd3e2b75010e2df732c::M1::Object" + "repr": "0x2ce2fe50016683a5ad096b8c1e8ea6c49de008c19cee60f38a4d51c92a475e6c::M1::Object" }, "json": { - "id": "0x36f05b1d8a31406630118071eb1742dfc0c6283062b254d8e8e64d24320fd382", - "value": "2" + "id": "0x5c76eac8095495f0bcb5569dd535172e4f4fdf76fedd97d97ebe3a332811f88a", + "value": "0" } } }, { - "version": 4, + "version": 6, "contents": { "type": { - "repr": "0xa9cbee3dea1fbcfbc892ff3689f58dc1620558f5f31f6cd3e2b75010e2df732c::M1::Object" + "repr": "0x2ce2fe50016683a5ad096b8c1e8ea6c49de008c19cee60f38a4d51c92a475e6c::M1::Object" }, "json": { - "id": "0x4c94d3aa104e529fdf2ce54b0813332b0b587d5b36d04ec87a9776db93ae093a", - "value": "1" + "id": "0x9844d52d8e6114c534d1c6f4ce72aa53e3b82c061765b50dbda7c0d1f403c604", + "value": "3" } } } diff --git a/crates/iota-graphql-e2e-tests/tests/consistency/objects_pagination_single.exp b/crates/iota-graphql-e2e-tests/tests/consistency/objects_pagination_single.exp index d71ecb2f586..e916dfe4b80 100644 --- a/crates/iota-graphql-e2e-tests/tests/consistency/objects_pagination_single.exp +++ b/crates/iota-graphql-e2e-tests/tests/consistency/objects_pagination_single.exp @@ -46,10 +46,10 @@ Response: { "version": 4, "contents": { "type": { - "repr": "0x9a9f3049a8b227506cd1f5b7dbd3dd0aa91af7f3a23e25ae4d189bd2e113be7e::M1::Object" + "repr": "0x5fa5759bca29623e75cb16a13373d58bd43e66ca4b9b7d5dc8fe13dd8f62621e::M1::Object" }, "json": { - "id": "0x17955f8b7d4669db399762e0f49286537d4b5cc715d098b704975cde14330807", + "id": "0xd5461cd6dc46396aca90b8e0993cae894e591eccae95f57a5554d6281985186c", "value": "100" } } @@ -85,10 +85,10 @@ Response: { "version": 4, "contents": { "type": { - "repr": "0x9a9f3049a8b227506cd1f5b7dbd3dd0aa91af7f3a23e25ae4d189bd2e113be7e::M1::Object" + "repr": "0x5fa5759bca29623e75cb16a13373d58bd43e66ca4b9b7d5dc8fe13dd8f62621e::M1::Object" }, "json": { - "id": "0x17955f8b7d4669db399762e0f49286537d4b5cc715d098b704975cde14330807", + "id": "0xd5461cd6dc46396aca90b8e0993cae894e591eccae95f57a5554d6281985186c", "value": "100" } } @@ -110,10 +110,10 @@ Response: { "version": 5, "contents": { "type": { - "repr": "0x9a9f3049a8b227506cd1f5b7dbd3dd0aa91af7f3a23e25ae4d189bd2e113be7e::M1::Object" + "repr": "0x5fa5759bca29623e75cb16a13373d58bd43e66ca4b9b7d5dc8fe13dd8f62621e::M1::Object" }, "json": { - "id": "0x17955f8b7d4669db399762e0f49286537d4b5cc715d098b704975cde14330807", + "id": "0xd5461cd6dc46396aca90b8e0993cae894e591eccae95f57a5554d6281985186c", "value": "200" } } @@ -122,10 +122,10 @@ Response: { "version": 4, "contents": { "type": { - "repr": "0x9a9f3049a8b227506cd1f5b7dbd3dd0aa91af7f3a23e25ae4d189bd2e113be7e::M1::Object" + "repr": "0x5fa5759bca29623e75cb16a13373d58bd43e66ca4b9b7d5dc8fe13dd8f62621e::M1::Object" }, "json": { - "id": "0xd7532dbf3fb07f34f65015771ec654b90c30249994723242054b88f36bd177d3", + "id": "0xddbf5f19a787733472a1307dee787bc19d81f35e79ab97eb23fbbcf8559304d4", "value": "1" } } @@ -145,10 +145,10 @@ Response: { "version": 5, "contents": { "type": { - "repr": "0x9a9f3049a8b227506cd1f5b7dbd3dd0aa91af7f3a23e25ae4d189bd2e113be7e::M1::Object" + "repr": "0x5fa5759bca29623e75cb16a13373d58bd43e66ca4b9b7d5dc8fe13dd8f62621e::M1::Object" }, "json": { - "id": "0x17955f8b7d4669db399762e0f49286537d4b5cc715d098b704975cde14330807", + "id": "0xd5461cd6dc46396aca90b8e0993cae894e591eccae95f57a5554d6281985186c", "value": "200" } }, @@ -160,10 +160,10 @@ Response: { "version": 5, "contents": { "type": { - "repr": "0x9a9f3049a8b227506cd1f5b7dbd3dd0aa91af7f3a23e25ae4d189bd2e113be7e::M1::Object" + "repr": "0x5fa5759bca29623e75cb16a13373d58bd43e66ca4b9b7d5dc8fe13dd8f62621e::M1::Object" }, "json": { - "id": "0x17955f8b7d4669db399762e0f49286537d4b5cc715d098b704975cde14330807", + "id": "0xd5461cd6dc46396aca90b8e0993cae894e591eccae95f57a5554d6281985186c", "value": "200" } } @@ -172,10 +172,10 @@ Response: { "version": 4, "contents": { "type": { - "repr": "0x9a9f3049a8b227506cd1f5b7dbd3dd0aa91af7f3a23e25ae4d189bd2e113be7e::M1::Object" + "repr": "0x5fa5759bca29623e75cb16a13373d58bd43e66ca4b9b7d5dc8fe13dd8f62621e::M1::Object" }, "json": { - "id": "0xd7532dbf3fb07f34f65015771ec654b90c30249994723242054b88f36bd177d3", + "id": "0xddbf5f19a787733472a1307dee787bc19d81f35e79ab97eb23fbbcf8559304d4", "value": "1" } } @@ -216,10 +216,10 @@ Response: { "version": 5, "contents": { "type": { - "repr": "0x9a9f3049a8b227506cd1f5b7dbd3dd0aa91af7f3a23e25ae4d189bd2e113be7e::M1::Object" + "repr": "0x5fa5759bca29623e75cb16a13373d58bd43e66ca4b9b7d5dc8fe13dd8f62621e::M1::Object" }, "json": { - "id": "0x17955f8b7d4669db399762e0f49286537d4b5cc715d098b704975cde14330807", + "id": "0xd5461cd6dc46396aca90b8e0993cae894e591eccae95f57a5554d6281985186c", "value": "200" } }, @@ -231,10 +231,10 @@ Response: { "version": 5, "contents": { "type": { - "repr": "0x9a9f3049a8b227506cd1f5b7dbd3dd0aa91af7f3a23e25ae4d189bd2e113be7e::M1::Object" + "repr": "0x5fa5759bca29623e75cb16a13373d58bd43e66ca4b9b7d5dc8fe13dd8f62621e::M1::Object" }, "json": { - "id": "0x17955f8b7d4669db399762e0f49286537d4b5cc715d098b704975cde14330807", + "id": "0xd5461cd6dc46396aca90b8e0993cae894e591eccae95f57a5554d6281985186c", "value": "200" } } @@ -243,10 +243,10 @@ Response: { "version": 4, "contents": { "type": { - "repr": "0x9a9f3049a8b227506cd1f5b7dbd3dd0aa91af7f3a23e25ae4d189bd2e113be7e::M1::Object" + "repr": "0x5fa5759bca29623e75cb16a13373d58bd43e66ca4b9b7d5dc8fe13dd8f62621e::M1::Object" }, "json": { - "id": "0xd7532dbf3fb07f34f65015771ec654b90c30249994723242054b88f36bd177d3", + "id": "0xddbf5f19a787733472a1307dee787bc19d81f35e79ab97eb23fbbcf8559304d4", "value": "1" } } @@ -273,10 +273,10 @@ Response: { "version": 5, "contents": { "type": { - "repr": "0x9a9f3049a8b227506cd1f5b7dbd3dd0aa91af7f3a23e25ae4d189bd2e113be7e::M1::Object" + "repr": "0x5fa5759bca29623e75cb16a13373d58bd43e66ca4b9b7d5dc8fe13dd8f62621e::M1::Object" }, "json": { - "id": "0x17955f8b7d4669db399762e0f49286537d4b5cc715d098b704975cde14330807", + "id": "0xd5461cd6dc46396aca90b8e0993cae894e591eccae95f57a5554d6281985186c", "value": "200" } } @@ -285,10 +285,10 @@ Response: { "version": 6, "contents": { "type": { - "repr": "0x9a9f3049a8b227506cd1f5b7dbd3dd0aa91af7f3a23e25ae4d189bd2e113be7e::M1::Object" + "repr": "0x5fa5759bca29623e75cb16a13373d58bd43e66ca4b9b7d5dc8fe13dd8f62621e::M1::Object" }, "json": { - "id": "0xd7532dbf3fb07f34f65015771ec654b90c30249994723242054b88f36bd177d3", + "id": "0xddbf5f19a787733472a1307dee787bc19d81f35e79ab97eb23fbbcf8559304d4", "value": "300" } } @@ -308,10 +308,10 @@ Response: { "version": 5, "contents": { "type": { - "repr": "0x9a9f3049a8b227506cd1f5b7dbd3dd0aa91af7f3a23e25ae4d189bd2e113be7e::M1::Object" + "repr": "0x5fa5759bca29623e75cb16a13373d58bd43e66ca4b9b7d5dc8fe13dd8f62621e::M1::Object" }, "json": { - "id": "0x17955f8b7d4669db399762e0f49286537d4b5cc715d098b704975cde14330807", + "id": "0xd5461cd6dc46396aca90b8e0993cae894e591eccae95f57a5554d6281985186c", "value": "200" } }, @@ -323,10 +323,10 @@ Response: { "version": 5, "contents": { "type": { - "repr": "0x9a9f3049a8b227506cd1f5b7dbd3dd0aa91af7f3a23e25ae4d189bd2e113be7e::M1::Object" + "repr": "0x5fa5759bca29623e75cb16a13373d58bd43e66ca4b9b7d5dc8fe13dd8f62621e::M1::Object" }, "json": { - "id": "0x17955f8b7d4669db399762e0f49286537d4b5cc715d098b704975cde14330807", + "id": "0xd5461cd6dc46396aca90b8e0993cae894e591eccae95f57a5554d6281985186c", "value": "200" } } @@ -335,10 +335,10 @@ Response: { "version": 6, "contents": { "type": { - "repr": "0x9a9f3049a8b227506cd1f5b7dbd3dd0aa91af7f3a23e25ae4d189bd2e113be7e::M1::Object" + "repr": "0x5fa5759bca29623e75cb16a13373d58bd43e66ca4b9b7d5dc8fe13dd8f62621e::M1::Object" }, "json": { - "id": "0xd7532dbf3fb07f34f65015771ec654b90c30249994723242054b88f36bd177d3", + "id": "0xddbf5f19a787733472a1307dee787bc19d81f35e79ab97eb23fbbcf8559304d4", "value": "300" } } diff --git a/crates/iota-graphql-e2e-tests/tests/consistency/performance/many_objects.exp b/crates/iota-graphql-e2e-tests/tests/consistency/performance/many_objects.exp index 51fd00a74af..825fcaf6369 100644 --- a/crates/iota-graphql-e2e-tests/tests/consistency/performance/many_objects.exp +++ b/crates/iota-graphql-e2e-tests/tests/consistency/performance/many_objects.exp @@ -35,11 +35,11 @@ Response: { }, "contents": { "json": { - "id": "0xfec432cac95eff36e85cb215430943ddc198ae47b8a22e325c1dcc542363b0a7", - "value": "222" + "id": "0xffab14ca154ad43c09db1837da78145762dc0181d54477753e13450a08f54ff3", + "value": "225" }, "type": { - "repr": "0xe3ea63728974cf03f1366718b6d9d3d3d8450e811ea17a4f77209e4b077a4423::M1::Object" + "repr": "0x4fed56e4707c2c3215eecdebd194f7d6a13c1e2005add7d5d076e82edfecabbf::M1::Object" } } } @@ -54,11 +54,11 @@ Response: { }, "contents": { "json": { - "id": "0xff9cd28672a00578a487ca017d55899a9d2bffe395546d4986e3d98251c8bc2b", - "value": "351" + "id": "0xffb620aa04580847eefb8133be8829adaa3ac33155927084561c44bb51310a1a", + "value": "385" }, "type": { - "repr": "0xe3ea63728974cf03f1366718b6d9d3d3d8450e811ea17a4f77209e4b077a4423::M1::Object" + "repr": "0x4fed56e4707c2c3215eecdebd194f7d6a13c1e2005add7d5d076e82edfecabbf::M1::Object" } } } @@ -76,11 +76,11 @@ Response: { }, "contents": { "json": { - "id": "0xfe513f99daeb9c6a48fac0f0cf25b99a30f6011207ce0608495d5532a5e44b14", - "value": "259" + "id": "0xfea66842c8932937f3017932a529561aee49bc62a64338bb0b1b6cc6f27bb8d0", + "value": "189" }, "type": { - "repr": "0xe3ea63728974cf03f1366718b6d9d3d3d8450e811ea17a4f77209e4b077a4423::M1::Object" + "repr": "0x4fed56e4707c2c3215eecdebd194f7d6a13c1e2005add7d5d076e82edfecabbf::M1::Object" } } }, @@ -92,11 +92,11 @@ Response: { }, "contents": { "json": { - "id": "0xfec21d038be0759da9ac70f793a5f4cd8de5e5c84bb1f731fead162a30959cd6", - "value": "299" + "id": "0xff48a550044bae201697197e3541eedbbbda0418f39f11e6a8eee3c5422d582a", + "value": "108" }, "type": { - "repr": "0xe3ea63728974cf03f1366718b6d9d3d3d8450e811ea17a4f77209e4b077a4423::M1::Object" + "repr": "0x4fed56e4707c2c3215eecdebd194f7d6a13c1e2005add7d5d076e82edfecabbf::M1::Object" } } }, @@ -108,11 +108,11 @@ Response: { }, "contents": { "json": { - "id": "0xfec432cac95eff36e85cb215430943ddc198ae47b8a22e325c1dcc542363b0a7", - "value": "222" + "id": "0xffab14ca154ad43c09db1837da78145762dc0181d54477753e13450a08f54ff3", + "value": "225" }, "type": { - "repr": "0xe3ea63728974cf03f1366718b6d9d3d3d8450e811ea17a4f77209e4b077a4423::M1::Object" + "repr": "0x4fed56e4707c2c3215eecdebd194f7d6a13c1e2005add7d5d076e82edfecabbf::M1::Object" } } }, @@ -124,11 +124,11 @@ Response: { }, "contents": { "json": { - "id": "0xff9cd28672a00578a487ca017d55899a9d2bffe395546d4986e3d98251c8bc2b", - "value": "351" + "id": "0xffb620aa04580847eefb8133be8829adaa3ac33155927084561c44bb51310a1a", + "value": "385" }, "type": { - "repr": "0xe3ea63728974cf03f1366718b6d9d3d3d8450e811ea17a4f77209e4b077a4423::M1::Object" + "repr": "0x4fed56e4707c2c3215eecdebd194f7d6a13c1e2005add7d5d076e82edfecabbf::M1::Object" } } } @@ -163,7 +163,7 @@ Contents: Test::M1::Object { bytes: fake(2,498), }, }, - value: 222u64, + value: 225u64, } task 9, line 93: @@ -176,7 +176,7 @@ Contents: Test::M1::Object { bytes: fake(2,497), }, }, - value: 299u64, + value: 108u64, } task 10, line 95: @@ -199,11 +199,11 @@ Response: { }, "contents": { "json": { - "id": "0xfec21d038be0759da9ac70f793a5f4cd8de5e5c84bb1f731fead162a30959cd6", - "value": "299" + "id": "0xff48a550044bae201697197e3541eedbbbda0418f39f11e6a8eee3c5422d582a", + "value": "108" }, "type": { - "repr": "0xe3ea63728974cf03f1366718b6d9d3d3d8450e811ea17a4f77209e4b077a4423::M1::Object" + "repr": "0x4fed56e4707c2c3215eecdebd194f7d6a13c1e2005add7d5d076e82edfecabbf::M1::Object" } } } @@ -218,11 +218,11 @@ Response: { }, "contents": { "json": { - "id": "0xfec432cac95eff36e85cb215430943ddc198ae47b8a22e325c1dcc542363b0a7", - "value": "222" + "id": "0xffab14ca154ad43c09db1837da78145762dc0181d54477753e13450a08f54ff3", + "value": "225" }, "type": { - "repr": "0xe3ea63728974cf03f1366718b6d9d3d3d8450e811ea17a4f77209e4b077a4423::M1::Object" + "repr": "0x4fed56e4707c2c3215eecdebd194f7d6a13c1e2005add7d5d076e82edfecabbf::M1::Object" } } } @@ -237,11 +237,11 @@ Response: { }, "contents": { "json": { - "id": "0xff9cd28672a00578a487ca017d55899a9d2bffe395546d4986e3d98251c8bc2b", - "value": "351" + "id": "0xffb620aa04580847eefb8133be8829adaa3ac33155927084561c44bb51310a1a", + "value": "385" }, "type": { - "repr": "0xe3ea63728974cf03f1366718b6d9d3d3d8450e811ea17a4f77209e4b077a4423::M1::Object" + "repr": "0x4fed56e4707c2c3215eecdebd194f7d6a13c1e2005add7d5d076e82edfecabbf::M1::Object" } } } @@ -260,11 +260,11 @@ Response: { }, "contents": { "json": { - "id": "0xfe513f99daeb9c6a48fac0f0cf25b99a30f6011207ce0608495d5532a5e44b14", - "value": "259" + "id": "0xfea66842c8932937f3017932a529561aee49bc62a64338bb0b1b6cc6f27bb8d0", + "value": "189" }, "type": { - "repr": "0xe3ea63728974cf03f1366718b6d9d3d3d8450e811ea17a4f77209e4b077a4423::M1::Object" + "repr": "0x4fed56e4707c2c3215eecdebd194f7d6a13c1e2005add7d5d076e82edfecabbf::M1::Object" } } } @@ -287,11 +287,11 @@ Response: { }, "contents": { "json": { - "id": "0xff9cd28672a00578a487ca017d55899a9d2bffe395546d4986e3d98251c8bc2b", - "value": "351" + "id": "0xffb620aa04580847eefb8133be8829adaa3ac33155927084561c44bb51310a1a", + "value": "385" }, "type": { - "repr": "0xe3ea63728974cf03f1366718b6d9d3d3d8450e811ea17a4f77209e4b077a4423::M1::Object" + "repr": "0x4fed56e4707c2c3215eecdebd194f7d6a13c1e2005add7d5d076e82edfecabbf::M1::Object" } } } @@ -305,11 +305,11 @@ Response: { }, "contents": { "json": { - "id": "0xff9cd28672a00578a487ca017d55899a9d2bffe395546d4986e3d98251c8bc2b", - "value": "351" + "id": "0xffb620aa04580847eefb8133be8829adaa3ac33155927084561c44bb51310a1a", + "value": "385" }, "type": { - "repr": "0xe3ea63728974cf03f1366718b6d9d3d3d8450e811ea17a4f77209e4b077a4423::M1::Object" + "repr": "0x4fed56e4707c2c3215eecdebd194f7d6a13c1e2005add7d5d076e82edfecabbf::M1::Object" } } } @@ -325,11 +325,11 @@ Response: { }, "contents": { "json": { - "id": "0xfec21d038be0759da9ac70f793a5f4cd8de5e5c84bb1f731fead162a30959cd6", - "value": "299" + "id": "0xff48a550044bae201697197e3541eedbbbda0418f39f11e6a8eee3c5422d582a", + "value": "108" }, "type": { - "repr": "0xe3ea63728974cf03f1366718b6d9d3d3d8450e811ea17a4f77209e4b077a4423::M1::Object" + "repr": "0x4fed56e4707c2c3215eecdebd194f7d6a13c1e2005add7d5d076e82edfecabbf::M1::Object" } } } @@ -343,11 +343,11 @@ Response: { }, "contents": { "json": { - "id": "0xfec432cac95eff36e85cb215430943ddc198ae47b8a22e325c1dcc542363b0a7", - "value": "222" + "id": "0xffab14ca154ad43c09db1837da78145762dc0181d54477753e13450a08f54ff3", + "value": "225" }, "type": { - "repr": "0xe3ea63728974cf03f1366718b6d9d3d3d8450e811ea17a4f77209e4b077a4423::M1::Object" + "repr": "0x4fed56e4707c2c3215eecdebd194f7d6a13c1e2005add7d5d076e82edfecabbf::M1::Object" } } } @@ -361,11 +361,11 @@ Response: { }, "contents": { "json": { - "id": "0xff9cd28672a00578a487ca017d55899a9d2bffe395546d4986e3d98251c8bc2b", - "value": "351" + "id": "0xffb620aa04580847eefb8133be8829adaa3ac33155927084561c44bb51310a1a", + "value": "385" }, "type": { - "repr": "0xe3ea63728974cf03f1366718b6d9d3d3d8450e811ea17a4f77209e4b077a4423::M1::Object" + "repr": "0x4fed56e4707c2c3215eecdebd194f7d6a13c1e2005add7d5d076e82edfecabbf::M1::Object" } } } @@ -383,11 +383,11 @@ Response: { }, "contents": { "json": { - "id": "0xfec21d038be0759da9ac70f793a5f4cd8de5e5c84bb1f731fead162a30959cd6", - "value": "299" + "id": "0xff48a550044bae201697197e3541eedbbbda0418f39f11e6a8eee3c5422d582a", + "value": "108" }, "type": { - "repr": "0xe3ea63728974cf03f1366718b6d9d3d3d8450e811ea17a4f77209e4b077a4423::M1::Object" + "repr": "0x4fed56e4707c2c3215eecdebd194f7d6a13c1e2005add7d5d076e82edfecabbf::M1::Object" } } } @@ -401,11 +401,11 @@ Response: { }, "contents": { "json": { - "id": "0xfec432cac95eff36e85cb215430943ddc198ae47b8a22e325c1dcc542363b0a7", - "value": "222" + "id": "0xffab14ca154ad43c09db1837da78145762dc0181d54477753e13450a08f54ff3", + "value": "225" }, "type": { - "repr": "0xe3ea63728974cf03f1366718b6d9d3d3d8450e811ea17a4f77209e4b077a4423::M1::Object" + "repr": "0x4fed56e4707c2c3215eecdebd194f7d6a13c1e2005add7d5d076e82edfecabbf::M1::Object" } } } @@ -419,11 +419,11 @@ Response: { }, "contents": { "json": { - "id": "0xff9cd28672a00578a487ca017d55899a9d2bffe395546d4986e3d98251c8bc2b", - "value": "351" + "id": "0xffb620aa04580847eefb8133be8829adaa3ac33155927084561c44bb51310a1a", + "value": "385" }, "type": { - "repr": "0xe3ea63728974cf03f1366718b6d9d3d3d8450e811ea17a4f77209e4b077a4423::M1::Object" + "repr": "0x4fed56e4707c2c3215eecdebd194f7d6a13c1e2005add7d5d076e82edfecabbf::M1::Object" } } } @@ -442,7 +442,7 @@ Response: { }, "contents": { "json": { - "id": "0x12458bdc1e04395483544cf98ec61de64bc9e2bf11bf8cc09121c266e151f623", + "id": "0x6214297c96396ed233024d61f0b882a1b3a3da30abc8ea6e234d93b7c2a0c6ae", "balance": { "value": "300000000000000" } @@ -461,11 +461,11 @@ Response: { }, "contents": { "json": { - "id": "0xfec21d038be0759da9ac70f793a5f4cd8de5e5c84bb1f731fead162a30959cd6", - "value": "299" + "id": "0xff48a550044bae201697197e3541eedbbbda0418f39f11e6a8eee3c5422d582a", + "value": "108" }, "type": { - "repr": "0xe3ea63728974cf03f1366718b6d9d3d3d8450e811ea17a4f77209e4b077a4423::M1::Object" + "repr": "0x4fed56e4707c2c3215eecdebd194f7d6a13c1e2005add7d5d076e82edfecabbf::M1::Object" } } }, @@ -478,11 +478,11 @@ Response: { }, "contents": { "json": { - "id": "0xfec432cac95eff36e85cb215430943ddc198ae47b8a22e325c1dcc542363b0a7", - "value": "222" + "id": "0xffab14ca154ad43c09db1837da78145762dc0181d54477753e13450a08f54ff3", + "value": "225" }, "type": { - "repr": "0xe3ea63728974cf03f1366718b6d9d3d3d8450e811ea17a4f77209e4b077a4423::M1::Object" + "repr": "0x4fed56e4707c2c3215eecdebd194f7d6a13c1e2005add7d5d076e82edfecabbf::M1::Object" } } }, @@ -495,11 +495,11 @@ Response: { }, "contents": { "json": { - "id": "0xff9cd28672a00578a487ca017d55899a9d2bffe395546d4986e3d98251c8bc2b", - "value": "351" + "id": "0xffb620aa04580847eefb8133be8829adaa3ac33155927084561c44bb51310a1a", + "value": "385" }, "type": { - "repr": "0xe3ea63728974cf03f1366718b6d9d3d3d8450e811ea17a4f77209e4b077a4423::M1::Object" + "repr": "0x4fed56e4707c2c3215eecdebd194f7d6a13c1e2005add7d5d076e82edfecabbf::M1::Object" } } } diff --git a/crates/iota-graphql-e2e-tests/tests/consistency/staked_iota.exp b/crates/iota-graphql-e2e-tests/tests/consistency/staked_iota.exp index 01f804555e1..0ab08a229ba 100644 --- a/crates/iota-graphql-e2e-tests/tests/consistency/staked_iota.exp +++ b/crates/iota-graphql-e2e-tests/tests/consistency/staked_iota.exp @@ -25,11 +25,11 @@ gas summary: computation_cost: 1000000, storage_cost: 1976000, storage_rebate: task 3, line 25: //# run 0x3::iota_system::request_add_stake --args object(0x5) object(2,0) @validator_0 --sender C -events: Event { package_id: iota_system, transaction_module: Identifier("iota_system"), sender: C, type_: StructTag { address: iota_system, module: Identifier("validator"), name: Identifier("StakingRequestEvent"), type_params: [] }, contents: [171, 56, 174, 116, 116, 231, 90, 122, 148, 80, 189, 213, 3, 8, 47, 190, 80, 171, 87, 32, 84, 9, 231, 203, 82, 3, 186, 181, 58, 235, 194, 1, 175, 163, 158, 79, 0, 218, 226, 120, 249, 119, 199, 198, 147, 10, 94, 44, 118, 232, 93, 23, 165, 38, 215, 36, 187, 206, 15, 184, 31, 176, 125, 76, 140, 202, 78, 28, 224, 186, 89, 4, 206, 166, 29, 249, 36, 45, 162, 247, 210, 158, 62, 243, 40, 251, 126, 192, 124, 8, 107, 59, 244, 124, 166, 26, 0, 0, 0, 0, 0, 0, 0, 0, 0, 228, 11, 84, 2, 0, 0, 0] } -created: object(3,0), object(3,1) -mutated: 0x0000000000000000000000000000000000000000000000000000000000000005, object(0,0) -deleted: object(_), object(2,0) -gas summary: computation_cost: 1000000, storage_cost: 14561600, storage_rebate: 1976000, non_refundable_storage_fee: 0 +events: Event { package_id: iota_system, transaction_module: Identifier("iota_system"), sender: C, type_: StructTag { address: iota_system, module: Identifier("validator"), name: Identifier("StakingRequestEvent"), type_params: [] }, contents: [135, 213, 224, 32, 91, 207, 0, 187, 34, 183, 14, 41, 167, 78, 77, 75, 138, 89, 173, 167, 170, 11, 38, 100, 45, 178, 245, 162, 113, 72, 177, 240, 175, 163, 158, 79, 0, 218, 226, 120, 249, 119, 199, 198, 147, 10, 94, 44, 118, 232, 93, 23, 165, 38, 215, 36, 187, 206, 15, 184, 31, 176, 125, 76, 140, 202, 78, 28, 224, 186, 89, 4, 206, 166, 29, 249, 36, 45, 162, 247, 210, 158, 62, 243, 40, 251, 126, 192, 124, 8, 107, 59, 244, 124, 166, 26, 0, 0, 0, 0, 0, 0, 0, 0, 0, 228, 11, 84, 2, 0, 0, 0] } +created: object(3,0) +mutated: object(_), 0x0000000000000000000000000000000000000000000000000000000000000005, object(0,0) +deleted: object(2,0) +gas summary: computation_cost: 1000000, storage_cost: 14523600, storage_rebate: 1976000, non_refundable_storage_fee: 0 task 4, line 27: //# create-checkpoint @@ -49,11 +49,11 @@ gas summary: computation_cost: 1000000, storage_cost: 1976000, storage_rebate: task 7, line 35: //# run 0x3::iota_system::request_add_stake --args object(0x5) object(6,0) @validator_0 --sender C -events: Event { package_id: iota_system, transaction_module: Identifier("iota_system"), sender: C, type_: StructTag { address: iota_system, module: Identifier("validator"), name: Identifier("StakingRequestEvent"), type_params: [] }, contents: [171, 56, 174, 116, 116, 231, 90, 122, 148, 80, 189, 213, 3, 8, 47, 190, 80, 171, 87, 32, 84, 9, 231, 203, 82, 3, 186, 181, 58, 235, 194, 1, 175, 163, 158, 79, 0, 218, 226, 120, 249, 119, 199, 198, 147, 10, 94, 44, 118, 232, 93, 23, 165, 38, 215, 36, 187, 206, 15, 184, 31, 176, 125, 76, 140, 202, 78, 28, 224, 186, 89, 4, 206, 166, 29, 249, 36, 45, 162, 247, 210, 158, 62, 243, 40, 251, 126, 192, 124, 8, 107, 59, 244, 124, 166, 26, 1, 0, 0, 0, 0, 0, 0, 0, 0, 228, 11, 84, 2, 0, 0, 0] } +events: Event { package_id: iota_system, transaction_module: Identifier("iota_system"), sender: C, type_: StructTag { address: iota_system, module: Identifier("validator"), name: Identifier("StakingRequestEvent"), type_params: [] }, contents: [135, 213, 224, 32, 91, 207, 0, 187, 34, 183, 14, 41, 167, 78, 77, 75, 138, 89, 173, 167, 170, 11, 38, 100, 45, 178, 245, 162, 113, 72, 177, 240, 175, 163, 158, 79, 0, 218, 226, 120, 249, 119, 199, 198, 147, 10, 94, 44, 118, 232, 93, 23, 165, 38, 215, 36, 187, 206, 15, 184, 31, 176, 125, 76, 140, 202, 78, 28, 224, 186, 89, 4, 206, 166, 29, 249, 36, 45, 162, 247, 210, 158, 62, 243, 40, 251, 126, 192, 124, 8, 107, 59, 244, 124, 166, 26, 1, 0, 0, 0, 0, 0, 0, 0, 0, 228, 11, 84, 2, 0, 0, 0] } created: object(7,0) -mutated: 0x0000000000000000000000000000000000000000000000000000000000000005, object(0,0), object(3,0) +mutated: object(_), 0x0000000000000000000000000000000000000000000000000000000000000005, object(0,0) deleted: object(6,0) -gas summary: computation_cost: 1000000, storage_cost: 14561600, storage_rebate: 14257600, non_refundable_storage_fee: 0 +gas summary: computation_cost: 1000000, storage_cost: 14523600, storage_rebate: 14219600, non_refundable_storage_fee: 0 task 8, line 37: //# create-checkpoint @@ -64,13 +64,13 @@ task 9, line 39: Epoch advanced: 1 task 10, line 41: -//# view-object 3,1 +//# view-object 3,0 Owner: Account Address ( C ) Version: 3 Contents: iota_system::staking_pool::StakedIota { id: iota::object::UID { id: iota::object::ID { - bytes: fake(3,1), + bytes: fake(3,0), }, }, pool_id: iota::object::ID { @@ -109,13 +109,13 @@ Response: { "stakedIotas": { "edges": [ { - "cursor": "ICyVnatyIW8BBQyropcZeyQEQxpFiSDIk5mD/WFlco2wBAAAAAAAAAA=", + "cursor": "IBI4Fo2NYBQFmwjdXvYZPRT977qOK/lqUGGG1hDgb5pdBAAAAAAAAAA=", "node": { "principal": "10000000000" } }, { - "cursor": "IFRKz2tTggQgu1xvCFWrIDLlqvonsA/vzDzPPN8u8UDtBAAAAAAAAAA=", + "cursor": "IKp2oYTL+6GLcESjpGjrpK2DOI3ytxsbPpDzuODNkWkaBAAAAAAAAAA=", "node": { "principal": "10000000000" } @@ -127,15 +127,15 @@ Response: { } task 13, lines 59-103: -//# run-graphql --cursors @{obj_3_1,1} @{obj_7_0,1} +//# run-graphql --cursors @{obj_3_0,1} @{obj_7_0,1} Response: { "data": { - "no_coins_after_obj_3_1_chkpt_1": { + "no_coins_after_obj_3_0_chkpt_1": { "stakedIotas": { "edges": [] } }, - "no_coins_before_obj_3_1_chkpt_1": { + "no_coins_before_obj_3_0_chkpt_1": { "stakedIotas": { "edges": [] } @@ -154,14 +154,19 @@ Response: { } task 14, lines 105-148: -//# run-graphql --cursors @{obj_3_1,3} @{obj_7_0,3} +//# run-graphql --cursors @{obj_3_0,3} @{obj_7_0,3} Response: { "data": { - "coins_after_obj_3_1_chkpt_3": { + "coins_after_obj_3_0_chkpt_3": { + "stakedIotas": { + "edges": [] + } + }, + "coins_before_obj_3_0_chkpt_3": { "stakedIotas": { "edges": [ { - "cursor": "IFRKz2tTggQgu1xvCFWrIDLlqvonsA/vzDzPPN8u8UDtAwAAAAAAAAA=", + "cursor": "IBI4Fo2NYBQFmwjdXvYZPRT977qOK/lqUGGG1hDgb5pdAwAAAAAAAAA=", "node": { "principal": "10000000000" } @@ -169,27 +174,22 @@ Response: { ] } }, - "coins_before_obj_3_1_chkpt_3": { - "stakedIotas": { - "edges": [] - } - }, "coins_after_obj_7_0_chkpt_3": { - "stakedIotas": { - "edges": [] - } - }, - "coins_before_obj_7_0_chkpt_3": { "stakedIotas": { "edges": [ { - "cursor": "ICyVnatyIW8BBQyropcZeyQEQxpFiSDIk5mD/WFlco2wAwAAAAAAAAA=", + "cursor": "IKp2oYTL+6GLcESjpGjrpK2DOI3ytxsbPpDzuODNkWkaAwAAAAAAAAA=", "node": { "principal": "10000000000" } } ] } + }, + "coins_before_obj_7_0_chkpt_3": { + "stakedIotas": { + "edges": [] + } } } } diff --git a/crates/iota-graphql-e2e-tests/tests/consistency/staked_iota.move b/crates/iota-graphql-e2e-tests/tests/consistency/staked_iota.move index fe21f0554f0..1b3366f414b 100644 --- a/crates/iota-graphql-e2e-tests/tests/consistency/staked_iota.move +++ b/crates/iota-graphql-e2e-tests/tests/consistency/staked_iota.move @@ -38,7 +38,7 @@ //# advance-epoch -//# view-object 3,1 +//# view-object 3,0 //# view-object 7,0 @@ -56,11 +56,11 @@ } } -//# run-graphql --cursors @{obj_3_1,1} @{obj_7_0,1} +//# run-graphql --cursors @{obj_3_0,1} @{obj_7_0,1} # Even though there is a stake created after the initial one, the cursor locks the upper bound to # checkpoint 1 - at that point in time, we did not have any additional stakes. { - no_coins_after_obj_3_1_chkpt_1: address(address: "@{C}") { + no_coins_after_obj_3_0_chkpt_1: address(address: "@{C}") { stakedIotas(after: "@{cursor_0}") { edges { cursor @@ -70,7 +70,7 @@ } } } - no_coins_before_obj_3_1_chkpt_1: address(address: "@{C}") { + no_coins_before_obj_3_0_chkpt_1: address(address: "@{C}") { stakedIotas(before: "@{cursor_0}") { edges { cursor @@ -102,11 +102,11 @@ } } -//# run-graphql --cursors @{obj_3_1,3} @{obj_7_0,3} +//# run-graphql --cursors @{obj_3_0,3} @{obj_7_0,3} # The second stake was created at checkpoint 3, and thus will be visible. { - coins_after_obj_3_1_chkpt_3: address(address: "@{C}") { - stakedIotas(after: "@{cursor_0}") { + coins_after_obj_3_0_chkpt_3: address(address: "@{C}") { + stakedIotas(after: "@{cursor_1}") { edges { cursor node { @@ -115,8 +115,8 @@ } } } - coins_before_obj_3_1_chkpt_3: address(address: "@{C}") { - stakedIotas(before: "@{cursor_0}") { + coins_before_obj_3_0_chkpt_3: address(address: "@{C}") { + stakedIotas(before: "@{cursor_1}") { edges { cursor node { @@ -126,7 +126,7 @@ } } coins_after_obj_7_0_chkpt_3: address(address: "@{C}") { - stakedIotas(after: "@{cursor_1}") { + stakedIotas(after: "@{cursor_0}") { edges { cursor node { @@ -136,7 +136,7 @@ } } coins_before_obj_7_0_chkpt_3: address(address: "@{C}") { - stakedIotas(before: "@{cursor_1}") { + stakedIotas(before: "@{cursor_0}") { edges { cursor node { diff --git a/crates/iota-graphql-e2e-tests/tests/consistency/tx_address_objects.exp b/crates/iota-graphql-e2e-tests/tests/consistency/tx_address_objects.exp index 950b02f0932..12640d34fb8 100644 --- a/crates/iota-graphql-e2e-tests/tests/consistency/tx_address_objects.exp +++ b/crates/iota-graphql-e2e-tests/tests/consistency/tx_address_objects.exp @@ -61,66 +61,66 @@ Response: { { "contents": { "json": { - "id": "0x1cf95cbbb66d52398519dbe561c026c8b2f8f3ca58294f162ad9a1f2957d6035", - "value": "3" + "id": "0x4f263537d7fe5e33e686f35580d88127cf67ca98fe3cce7dd910635eba391586", + "value": "4" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x20f00cdc31f4b422ecda21ace92ea2ade64d9a5aa38c03cf526a7f67836deff0", - "value": "2" + "id": "0x5941bc00a228a02d0db39d77f0cf61e36dbe9a1013f273e9ed0ee02eb3259160", + "value": "5" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x27204d98aadcf334e4b1a4fa39208c260669339c83808e2eb04e7ad4b1ba01cd", - "value": "5" + "id": "0x620fc261f44d1a27f42d6c8bd9d95c22c781966926056c56e4274140ba02d1b6", + "value": "3" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x82ef8d537fb2fe2c4a35f50cec7d8e46a96ffa1e76f90a66144b3e247696d17d", + "id": "0xaed872c4119b75506c212811899e9414db6106e3f687222db8833062003fa46e", "value": "200" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x96a37c40cad4455aedf4d66f8d94aa9f91542bf2a6766f0669cf91058f82c0ed", - "value": "4" + "id": "0xba33c3291e8547a7ee8c971c786ffa720d3df52650e5ff493be10d52c86688d9", + "value": "6" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0xdfa6c182e56bdcafb49a262da0da5ed17a58b8d53e9e4378baebc71748b5b3dc", - "value": "6" + "id": "0xc331b92ab20dd4a424b17a2c0bf507b935a92f84caee9b6f9717a61dc356607c", + "value": "2" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } } @@ -136,66 +136,66 @@ Response: { { "contents": { "json": { - "id": "0x1cf95cbbb66d52398519dbe561c026c8b2f8f3ca58294f162ad9a1f2957d6035", - "value": "3" + "id": "0x4f263537d7fe5e33e686f35580d88127cf67ca98fe3cce7dd910635eba391586", + "value": "4" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x20f00cdc31f4b422ecda21ace92ea2ade64d9a5aa38c03cf526a7f67836deff0", - "value": "2" + "id": "0x5941bc00a228a02d0db39d77f0cf61e36dbe9a1013f273e9ed0ee02eb3259160", + "value": "5" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x27204d98aadcf334e4b1a4fa39208c260669339c83808e2eb04e7ad4b1ba01cd", - "value": "5" + "id": "0x620fc261f44d1a27f42d6c8bd9d95c22c781966926056c56e4274140ba02d1b6", + "value": "3" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x82ef8d537fb2fe2c4a35f50cec7d8e46a96ffa1e76f90a66144b3e247696d17d", + "id": "0xaed872c4119b75506c212811899e9414db6106e3f687222db8833062003fa46e", "value": "200" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x96a37c40cad4455aedf4d66f8d94aa9f91542bf2a6766f0669cf91058f82c0ed", - "value": "4" + "id": "0xba33c3291e8547a7ee8c971c786ffa720d3df52650e5ff493be10d52c86688d9", + "value": "6" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0xdfa6c182e56bdcafb49a262da0da5ed17a58b8d53e9e4378baebc71748b5b3dc", - "value": "6" + "id": "0xc331b92ab20dd4a424b17a2c0bf507b935a92f84caee9b6f9717a61dc356607c", + "value": "2" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } } @@ -209,66 +209,66 @@ Response: { { "contents": { "json": { - "id": "0x1cf95cbbb66d52398519dbe561c026c8b2f8f3ca58294f162ad9a1f2957d6035", - "value": "3" + "id": "0x4f263537d7fe5e33e686f35580d88127cf67ca98fe3cce7dd910635eba391586", + "value": "4" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x20f00cdc31f4b422ecda21ace92ea2ade64d9a5aa38c03cf526a7f67836deff0", - "value": "2" + "id": "0x5941bc00a228a02d0db39d77f0cf61e36dbe9a1013f273e9ed0ee02eb3259160", + "value": "5" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x27204d98aadcf334e4b1a4fa39208c260669339c83808e2eb04e7ad4b1ba01cd", - "value": "5" + "id": "0x620fc261f44d1a27f42d6c8bd9d95c22c781966926056c56e4274140ba02d1b6", + "value": "3" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x82ef8d537fb2fe2c4a35f50cec7d8e46a96ffa1e76f90a66144b3e247696d17d", + "id": "0xaed872c4119b75506c212811899e9414db6106e3f687222db8833062003fa46e", "value": "200" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x96a37c40cad4455aedf4d66f8d94aa9f91542bf2a6766f0669cf91058f82c0ed", - "value": "4" + "id": "0xba33c3291e8547a7ee8c971c786ffa720d3df52650e5ff493be10d52c86688d9", + "value": "6" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0xdfa6c182e56bdcafb49a262da0da5ed17a58b8d53e9e4378baebc71748b5b3dc", - "value": "6" + "id": "0xc331b92ab20dd4a424b17a2c0bf507b935a92f84caee9b6f9717a61dc356607c", + "value": "2" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } } @@ -284,7 +284,7 @@ Response: { "repr": "0x0000000000000000000000000000000000000000000000000000000000000002::coin::Coin<0x0000000000000000000000000000000000000000000000000000000000000002::iota::IOTA>" }, "json": { - "id": "0x875b7011e8f9650ccf26b682b6aeeb36050f9665157d47407e2925700e69143b", + "id": "0x1fd0f50cd017f97b048a4a779dbc67cb5387d17a79984b1819a429b7ffb4ef53", "balance": { "value": "299999993067600" } @@ -306,66 +306,66 @@ Response: { { "contents": { "json": { - "id": "0x1cf95cbbb66d52398519dbe561c026c8b2f8f3ca58294f162ad9a1f2957d6035", - "value": "3" + "id": "0x4f263537d7fe5e33e686f35580d88127cf67ca98fe3cce7dd910635eba391586", + "value": "4" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x20f00cdc31f4b422ecda21ace92ea2ade64d9a5aa38c03cf526a7f67836deff0", - "value": "2" + "id": "0x5941bc00a228a02d0db39d77f0cf61e36dbe9a1013f273e9ed0ee02eb3259160", + "value": "5" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x27204d98aadcf334e4b1a4fa39208c260669339c83808e2eb04e7ad4b1ba01cd", - "value": "5" + "id": "0x620fc261f44d1a27f42d6c8bd9d95c22c781966926056c56e4274140ba02d1b6", + "value": "3" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x82ef8d537fb2fe2c4a35f50cec7d8e46a96ffa1e76f90a66144b3e247696d17d", + "id": "0xaed872c4119b75506c212811899e9414db6106e3f687222db8833062003fa46e", "value": "200" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x96a37c40cad4455aedf4d66f8d94aa9f91542bf2a6766f0669cf91058f82c0ed", - "value": "4" + "id": "0xba33c3291e8547a7ee8c971c786ffa720d3df52650e5ff493be10d52c86688d9", + "value": "6" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0xdfa6c182e56bdcafb49a262da0da5ed17a58b8d53e9e4378baebc71748b5b3dc", - "value": "6" + "id": "0xc331b92ab20dd4a424b17a2c0bf507b935a92f84caee9b6f9717a61dc356607c", + "value": "2" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } } @@ -390,66 +390,66 @@ Response: { { "contents": { "json": { - "id": "0x1cf95cbbb66d52398519dbe561c026c8b2f8f3ca58294f162ad9a1f2957d6035", - "value": "3" + "id": "0x4f263537d7fe5e33e686f35580d88127cf67ca98fe3cce7dd910635eba391586", + "value": "4" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x20f00cdc31f4b422ecda21ace92ea2ade64d9a5aa38c03cf526a7f67836deff0", - "value": "2" + "id": "0x5941bc00a228a02d0db39d77f0cf61e36dbe9a1013f273e9ed0ee02eb3259160", + "value": "5" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x27204d98aadcf334e4b1a4fa39208c260669339c83808e2eb04e7ad4b1ba01cd", - "value": "5" + "id": "0x620fc261f44d1a27f42d6c8bd9d95c22c781966926056c56e4274140ba02d1b6", + "value": "3" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x82ef8d537fb2fe2c4a35f50cec7d8e46a96ffa1e76f90a66144b3e247696d17d", + "id": "0xaed872c4119b75506c212811899e9414db6106e3f687222db8833062003fa46e", "value": "200" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x96a37c40cad4455aedf4d66f8d94aa9f91542bf2a6766f0669cf91058f82c0ed", - "value": "4" + "id": "0xba33c3291e8547a7ee8c971c786ffa720d3df52650e5ff493be10d52c86688d9", + "value": "6" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0xdfa6c182e56bdcafb49a262da0da5ed17a58b8d53e9e4378baebc71748b5b3dc", - "value": "6" + "id": "0xc331b92ab20dd4a424b17a2c0bf507b935a92f84caee9b6f9717a61dc356607c", + "value": "2" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } } @@ -463,66 +463,66 @@ Response: { { "contents": { "json": { - "id": "0x1cf95cbbb66d52398519dbe561c026c8b2f8f3ca58294f162ad9a1f2957d6035", - "value": "3" + "id": "0x4f263537d7fe5e33e686f35580d88127cf67ca98fe3cce7dd910635eba391586", + "value": "4" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x20f00cdc31f4b422ecda21ace92ea2ade64d9a5aa38c03cf526a7f67836deff0", - "value": "2" + "id": "0x5941bc00a228a02d0db39d77f0cf61e36dbe9a1013f273e9ed0ee02eb3259160", + "value": "5" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x27204d98aadcf334e4b1a4fa39208c260669339c83808e2eb04e7ad4b1ba01cd", - "value": "5" + "id": "0x620fc261f44d1a27f42d6c8bd9d95c22c781966926056c56e4274140ba02d1b6", + "value": "3" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x82ef8d537fb2fe2c4a35f50cec7d8e46a96ffa1e76f90a66144b3e247696d17d", + "id": "0xaed872c4119b75506c212811899e9414db6106e3f687222db8833062003fa46e", "value": "200" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x96a37c40cad4455aedf4d66f8d94aa9f91542bf2a6766f0669cf91058f82c0ed", - "value": "4" + "id": "0xba33c3291e8547a7ee8c971c786ffa720d3df52650e5ff493be10d52c86688d9", + "value": "6" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0xdfa6c182e56bdcafb49a262da0da5ed17a58b8d53e9e4378baebc71748b5b3dc", - "value": "6" + "id": "0xc331b92ab20dd4a424b17a2c0bf507b935a92f84caee9b6f9717a61dc356607c", + "value": "2" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } } @@ -538,7 +538,7 @@ Response: { "repr": "0x0000000000000000000000000000000000000000000000000000000000000002::coin::Coin<0x0000000000000000000000000000000000000000000000000000000000000002::iota::IOTA>" }, "json": { - "id": "0x875b7011e8f9650ccf26b682b6aeeb36050f9665157d47407e2925700e69143b", + "id": "0x1fd0f50cd017f97b048a4a779dbc67cb5387d17a79984b1819a429b7ffb4ef53", "balance": { "value": "300000000000000" } @@ -557,66 +557,66 @@ Response: { { "contents": { "json": { - "id": "0x1cf95cbbb66d52398519dbe561c026c8b2f8f3ca58294f162ad9a1f2957d6035", - "value": "3" + "id": "0x4f263537d7fe5e33e686f35580d88127cf67ca98fe3cce7dd910635eba391586", + "value": "4" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x20f00cdc31f4b422ecda21ace92ea2ade64d9a5aa38c03cf526a7f67836deff0", - "value": "2" + "id": "0x5941bc00a228a02d0db39d77f0cf61e36dbe9a1013f273e9ed0ee02eb3259160", + "value": "5" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x27204d98aadcf334e4b1a4fa39208c260669339c83808e2eb04e7ad4b1ba01cd", - "value": "5" + "id": "0x620fc261f44d1a27f42d6c8bd9d95c22c781966926056c56e4274140ba02d1b6", + "value": "3" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x82ef8d537fb2fe2c4a35f50cec7d8e46a96ffa1e76f90a66144b3e247696d17d", + "id": "0xaed872c4119b75506c212811899e9414db6106e3f687222db8833062003fa46e", "value": "200" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x96a37c40cad4455aedf4d66f8d94aa9f91542bf2a6766f0669cf91058f82c0ed", - "value": "4" + "id": "0xba33c3291e8547a7ee8c971c786ffa720d3df52650e5ff493be10d52c86688d9", + "value": "6" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0xdfa6c182e56bdcafb49a262da0da5ed17a58b8d53e9e4378baebc71748b5b3dc", - "value": "6" + "id": "0xc331b92ab20dd4a424b17a2c0bf507b935a92f84caee9b6f9717a61dc356607c", + "value": "2" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } } @@ -630,66 +630,66 @@ Response: { { "contents": { "json": { - "id": "0x1cf95cbbb66d52398519dbe561c026c8b2f8f3ca58294f162ad9a1f2957d6035", - "value": "3" + "id": "0x4f263537d7fe5e33e686f35580d88127cf67ca98fe3cce7dd910635eba391586", + "value": "4" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x20f00cdc31f4b422ecda21ace92ea2ade64d9a5aa38c03cf526a7f67836deff0", - "value": "2" + "id": "0x5941bc00a228a02d0db39d77f0cf61e36dbe9a1013f273e9ed0ee02eb3259160", + "value": "5" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x27204d98aadcf334e4b1a4fa39208c260669339c83808e2eb04e7ad4b1ba01cd", - "value": "5" + "id": "0x620fc261f44d1a27f42d6c8bd9d95c22c781966926056c56e4274140ba02d1b6", + "value": "3" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x82ef8d537fb2fe2c4a35f50cec7d8e46a96ffa1e76f90a66144b3e247696d17d", + "id": "0xaed872c4119b75506c212811899e9414db6106e3f687222db8833062003fa46e", "value": "200" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x96a37c40cad4455aedf4d66f8d94aa9f91542bf2a6766f0669cf91058f82c0ed", - "value": "4" + "id": "0xba33c3291e8547a7ee8c971c786ffa720d3df52650e5ff493be10d52c86688d9", + "value": "6" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0xdfa6c182e56bdcafb49a262da0da5ed17a58b8d53e9e4378baebc71748b5b3dc", - "value": "6" + "id": "0xc331b92ab20dd4a424b17a2c0bf507b935a92f84caee9b6f9717a61dc356607c", + "value": "2" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } } @@ -705,7 +705,7 @@ Response: { "repr": "0x0000000000000000000000000000000000000000000000000000000000000002::coin::Coin<0x0000000000000000000000000000000000000000000000000000000000000002::iota::IOTA>" }, "json": { - "id": "0x875b7011e8f9650ccf26b682b6aeeb36050f9665157d47407e2925700e69143b", + "id": "0x1fd0f50cd017f97b048a4a779dbc67cb5387d17a79984b1819a429b7ffb4ef53", "balance": { "value": "299999996697200" } @@ -724,66 +724,66 @@ Response: { { "contents": { "json": { - "id": "0x1cf95cbbb66d52398519dbe561c026c8b2f8f3ca58294f162ad9a1f2957d6035", - "value": "3" + "id": "0x4f263537d7fe5e33e686f35580d88127cf67ca98fe3cce7dd910635eba391586", + "value": "4" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x20f00cdc31f4b422ecda21ace92ea2ade64d9a5aa38c03cf526a7f67836deff0", - "value": "2" + "id": "0x5941bc00a228a02d0db39d77f0cf61e36dbe9a1013f273e9ed0ee02eb3259160", + "value": "5" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x27204d98aadcf334e4b1a4fa39208c260669339c83808e2eb04e7ad4b1ba01cd", - "value": "5" + "id": "0x620fc261f44d1a27f42d6c8bd9d95c22c781966926056c56e4274140ba02d1b6", + "value": "3" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x82ef8d537fb2fe2c4a35f50cec7d8e46a96ffa1e76f90a66144b3e247696d17d", + "id": "0xaed872c4119b75506c212811899e9414db6106e3f687222db8833062003fa46e", "value": "200" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x96a37c40cad4455aedf4d66f8d94aa9f91542bf2a6766f0669cf91058f82c0ed", - "value": "4" + "id": "0xba33c3291e8547a7ee8c971c786ffa720d3df52650e5ff493be10d52c86688d9", + "value": "6" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0xdfa6c182e56bdcafb49a262da0da5ed17a58b8d53e9e4378baebc71748b5b3dc", - "value": "6" + "id": "0xc331b92ab20dd4a424b17a2c0bf507b935a92f84caee9b6f9717a61dc356607c", + "value": "2" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } } @@ -797,66 +797,66 @@ Response: { { "contents": { "json": { - "id": "0x1cf95cbbb66d52398519dbe561c026c8b2f8f3ca58294f162ad9a1f2957d6035", - "value": "3" + "id": "0x4f263537d7fe5e33e686f35580d88127cf67ca98fe3cce7dd910635eba391586", + "value": "4" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x20f00cdc31f4b422ecda21ace92ea2ade64d9a5aa38c03cf526a7f67836deff0", - "value": "2" + "id": "0x5941bc00a228a02d0db39d77f0cf61e36dbe9a1013f273e9ed0ee02eb3259160", + "value": "5" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x27204d98aadcf334e4b1a4fa39208c260669339c83808e2eb04e7ad4b1ba01cd", - "value": "5" + "id": "0x620fc261f44d1a27f42d6c8bd9d95c22c781966926056c56e4274140ba02d1b6", + "value": "3" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x82ef8d537fb2fe2c4a35f50cec7d8e46a96ffa1e76f90a66144b3e247696d17d", + "id": "0xaed872c4119b75506c212811899e9414db6106e3f687222db8833062003fa46e", "value": "200" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x96a37c40cad4455aedf4d66f8d94aa9f91542bf2a6766f0669cf91058f82c0ed", - "value": "4" + "id": "0xba33c3291e8547a7ee8c971c786ffa720d3df52650e5ff493be10d52c86688d9", + "value": "6" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0xdfa6c182e56bdcafb49a262da0da5ed17a58b8d53e9e4378baebc71748b5b3dc", - "value": "6" + "id": "0xc331b92ab20dd4a424b17a2c0bf507b935a92f84caee9b6f9717a61dc356607c", + "value": "2" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } } @@ -872,7 +872,7 @@ Response: { "repr": "0x0000000000000000000000000000000000000000000000000000000000000002::coin::Coin<0x0000000000000000000000000000000000000000000000000000000000000002::iota::IOTA>" }, "json": { - "id": "0x875b7011e8f9650ccf26b682b6aeeb36050f9665157d47407e2925700e69143b", + "id": "0x1fd0f50cd017f97b048a4a779dbc67cb5387d17a79984b1819a429b7ffb4ef53", "balance": { "value": "299999993067600" } @@ -907,66 +907,66 @@ Response: { { "contents": { "json": { - "id": "0x1cf95cbbb66d52398519dbe561c026c8b2f8f3ca58294f162ad9a1f2957d6035", - "value": "3" + "id": "0x4f263537d7fe5e33e686f35580d88127cf67ca98fe3cce7dd910635eba391586", + "value": "4" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x20f00cdc31f4b422ecda21ace92ea2ade64d9a5aa38c03cf526a7f67836deff0", - "value": "2" + "id": "0x5941bc00a228a02d0db39d77f0cf61e36dbe9a1013f273e9ed0ee02eb3259160", + "value": "5" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x27204d98aadcf334e4b1a4fa39208c260669339c83808e2eb04e7ad4b1ba01cd", - "value": "5" + "id": "0x620fc261f44d1a27f42d6c8bd9d95c22c781966926056c56e4274140ba02d1b6", + "value": "3" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x82ef8d537fb2fe2c4a35f50cec7d8e46a96ffa1e76f90a66144b3e247696d17d", + "id": "0xaed872c4119b75506c212811899e9414db6106e3f687222db8833062003fa46e", "value": "200" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x96a37c40cad4455aedf4d66f8d94aa9f91542bf2a6766f0669cf91058f82c0ed", - "value": "4" + "id": "0xba33c3291e8547a7ee8c971c786ffa720d3df52650e5ff493be10d52c86688d9", + "value": "6" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0xdfa6c182e56bdcafb49a262da0da5ed17a58b8d53e9e4378baebc71748b5b3dc", - "value": "6" + "id": "0xc331b92ab20dd4a424b17a2c0bf507b935a92f84caee9b6f9717a61dc356607c", + "value": "2" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } } @@ -982,66 +982,66 @@ Response: { { "contents": { "json": { - "id": "0x1cf95cbbb66d52398519dbe561c026c8b2f8f3ca58294f162ad9a1f2957d6035", - "value": "3" + "id": "0x4f263537d7fe5e33e686f35580d88127cf67ca98fe3cce7dd910635eba391586", + "value": "4" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x20f00cdc31f4b422ecda21ace92ea2ade64d9a5aa38c03cf526a7f67836deff0", - "value": "2" + "id": "0x5941bc00a228a02d0db39d77f0cf61e36dbe9a1013f273e9ed0ee02eb3259160", + "value": "5" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x27204d98aadcf334e4b1a4fa39208c260669339c83808e2eb04e7ad4b1ba01cd", - "value": "5" + "id": "0x620fc261f44d1a27f42d6c8bd9d95c22c781966926056c56e4274140ba02d1b6", + "value": "3" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x82ef8d537fb2fe2c4a35f50cec7d8e46a96ffa1e76f90a66144b3e247696d17d", + "id": "0xaed872c4119b75506c212811899e9414db6106e3f687222db8833062003fa46e", "value": "200" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x96a37c40cad4455aedf4d66f8d94aa9f91542bf2a6766f0669cf91058f82c0ed", - "value": "4" + "id": "0xba33c3291e8547a7ee8c971c786ffa720d3df52650e5ff493be10d52c86688d9", + "value": "6" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0xdfa6c182e56bdcafb49a262da0da5ed17a58b8d53e9e4378baebc71748b5b3dc", - "value": "6" + "id": "0xc331b92ab20dd4a424b17a2c0bf507b935a92f84caee9b6f9717a61dc356607c", + "value": "2" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } } @@ -1055,66 +1055,66 @@ Response: { { "contents": { "json": { - "id": "0x1cf95cbbb66d52398519dbe561c026c8b2f8f3ca58294f162ad9a1f2957d6035", - "value": "3" + "id": "0x4f263537d7fe5e33e686f35580d88127cf67ca98fe3cce7dd910635eba391586", + "value": "4" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x20f00cdc31f4b422ecda21ace92ea2ade64d9a5aa38c03cf526a7f67836deff0", - "value": "2" + "id": "0x5941bc00a228a02d0db39d77f0cf61e36dbe9a1013f273e9ed0ee02eb3259160", + "value": "5" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x27204d98aadcf334e4b1a4fa39208c260669339c83808e2eb04e7ad4b1ba01cd", - "value": "5" + "id": "0x620fc261f44d1a27f42d6c8bd9d95c22c781966926056c56e4274140ba02d1b6", + "value": "3" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x82ef8d537fb2fe2c4a35f50cec7d8e46a96ffa1e76f90a66144b3e247696d17d", + "id": "0xaed872c4119b75506c212811899e9414db6106e3f687222db8833062003fa46e", "value": "200" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x96a37c40cad4455aedf4d66f8d94aa9f91542bf2a6766f0669cf91058f82c0ed", - "value": "4" + "id": "0xba33c3291e8547a7ee8c971c786ffa720d3df52650e5ff493be10d52c86688d9", + "value": "6" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0xdfa6c182e56bdcafb49a262da0da5ed17a58b8d53e9e4378baebc71748b5b3dc", - "value": "6" + "id": "0xc331b92ab20dd4a424b17a2c0bf507b935a92f84caee9b6f9717a61dc356607c", + "value": "2" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } } @@ -1130,7 +1130,7 @@ Response: { "repr": "0x0000000000000000000000000000000000000000000000000000000000000002::coin::Coin<0x0000000000000000000000000000000000000000000000000000000000000002::iota::IOTA>" }, "json": { - "id": "0x875b7011e8f9650ccf26b682b6aeeb36050f9665157d47407e2925700e69143b", + "id": "0x1fd0f50cd017f97b048a4a779dbc67cb5387d17a79984b1819a429b7ffb4ef53", "balance": { "value": "299999993067600" } @@ -1152,66 +1152,66 @@ Response: { { "contents": { "json": { - "id": "0x1cf95cbbb66d52398519dbe561c026c8b2f8f3ca58294f162ad9a1f2957d6035", - "value": "3" + "id": "0x4f263537d7fe5e33e686f35580d88127cf67ca98fe3cce7dd910635eba391586", + "value": "4" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x20f00cdc31f4b422ecda21ace92ea2ade64d9a5aa38c03cf526a7f67836deff0", - "value": "2" + "id": "0x5941bc00a228a02d0db39d77f0cf61e36dbe9a1013f273e9ed0ee02eb3259160", + "value": "5" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x27204d98aadcf334e4b1a4fa39208c260669339c83808e2eb04e7ad4b1ba01cd", - "value": "5" + "id": "0x620fc261f44d1a27f42d6c8bd9d95c22c781966926056c56e4274140ba02d1b6", + "value": "3" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x82ef8d537fb2fe2c4a35f50cec7d8e46a96ffa1e76f90a66144b3e247696d17d", + "id": "0xaed872c4119b75506c212811899e9414db6106e3f687222db8833062003fa46e", "value": "200" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x96a37c40cad4455aedf4d66f8d94aa9f91542bf2a6766f0669cf91058f82c0ed", - "value": "4" + "id": "0xba33c3291e8547a7ee8c971c786ffa720d3df52650e5ff493be10d52c86688d9", + "value": "6" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0xdfa6c182e56bdcafb49a262da0da5ed17a58b8d53e9e4378baebc71748b5b3dc", - "value": "6" + "id": "0xc331b92ab20dd4a424b17a2c0bf507b935a92f84caee9b6f9717a61dc356607c", + "value": "2" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } } @@ -1240,66 +1240,66 @@ Response: { { "contents": { "json": { - "id": "0x1cf95cbbb66d52398519dbe561c026c8b2f8f3ca58294f162ad9a1f2957d6035", - "value": "3" + "id": "0x4f263537d7fe5e33e686f35580d88127cf67ca98fe3cce7dd910635eba391586", + "value": "4" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x20f00cdc31f4b422ecda21ace92ea2ade64d9a5aa38c03cf526a7f67836deff0", - "value": "2" + "id": "0x5941bc00a228a02d0db39d77f0cf61e36dbe9a1013f273e9ed0ee02eb3259160", + "value": "5" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x27204d98aadcf334e4b1a4fa39208c260669339c83808e2eb04e7ad4b1ba01cd", - "value": "5" + "id": "0x620fc261f44d1a27f42d6c8bd9d95c22c781966926056c56e4274140ba02d1b6", + "value": "3" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x82ef8d537fb2fe2c4a35f50cec7d8e46a96ffa1e76f90a66144b3e247696d17d", + "id": "0xaed872c4119b75506c212811899e9414db6106e3f687222db8833062003fa46e", "value": "200" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x96a37c40cad4455aedf4d66f8d94aa9f91542bf2a6766f0669cf91058f82c0ed", - "value": "4" + "id": "0xba33c3291e8547a7ee8c971c786ffa720d3df52650e5ff493be10d52c86688d9", + "value": "6" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0xdfa6c182e56bdcafb49a262da0da5ed17a58b8d53e9e4378baebc71748b5b3dc", - "value": "6" + "id": "0xc331b92ab20dd4a424b17a2c0bf507b935a92f84caee9b6f9717a61dc356607c", + "value": "2" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } } @@ -1313,66 +1313,66 @@ Response: { { "contents": { "json": { - "id": "0x1cf95cbbb66d52398519dbe561c026c8b2f8f3ca58294f162ad9a1f2957d6035", - "value": "3" + "id": "0x4f263537d7fe5e33e686f35580d88127cf67ca98fe3cce7dd910635eba391586", + "value": "4" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x20f00cdc31f4b422ecda21ace92ea2ade64d9a5aa38c03cf526a7f67836deff0", - "value": "2" + "id": "0x5941bc00a228a02d0db39d77f0cf61e36dbe9a1013f273e9ed0ee02eb3259160", + "value": "5" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x27204d98aadcf334e4b1a4fa39208c260669339c83808e2eb04e7ad4b1ba01cd", - "value": "5" + "id": "0x620fc261f44d1a27f42d6c8bd9d95c22c781966926056c56e4274140ba02d1b6", + "value": "3" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x82ef8d537fb2fe2c4a35f50cec7d8e46a96ffa1e76f90a66144b3e247696d17d", + "id": "0xaed872c4119b75506c212811899e9414db6106e3f687222db8833062003fa46e", "value": "200" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x96a37c40cad4455aedf4d66f8d94aa9f91542bf2a6766f0669cf91058f82c0ed", - "value": "4" + "id": "0xba33c3291e8547a7ee8c971c786ffa720d3df52650e5ff493be10d52c86688d9", + "value": "6" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0xdfa6c182e56bdcafb49a262da0da5ed17a58b8d53e9e4378baebc71748b5b3dc", - "value": "6" + "id": "0xc331b92ab20dd4a424b17a2c0bf507b935a92f84caee9b6f9717a61dc356607c", + "value": "2" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } } @@ -1388,66 +1388,66 @@ Response: { { "contents": { "json": { - "id": "0x1cf95cbbb66d52398519dbe561c026c8b2f8f3ca58294f162ad9a1f2957d6035", - "value": "3" + "id": "0x4f263537d7fe5e33e686f35580d88127cf67ca98fe3cce7dd910635eba391586", + "value": "4" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x20f00cdc31f4b422ecda21ace92ea2ade64d9a5aa38c03cf526a7f67836deff0", - "value": "2" + "id": "0x5941bc00a228a02d0db39d77f0cf61e36dbe9a1013f273e9ed0ee02eb3259160", + "value": "5" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x27204d98aadcf334e4b1a4fa39208c260669339c83808e2eb04e7ad4b1ba01cd", - "value": "5" + "id": "0x620fc261f44d1a27f42d6c8bd9d95c22c781966926056c56e4274140ba02d1b6", + "value": "3" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x82ef8d537fb2fe2c4a35f50cec7d8e46a96ffa1e76f90a66144b3e247696d17d", + "id": "0xaed872c4119b75506c212811899e9414db6106e3f687222db8833062003fa46e", "value": "200" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x96a37c40cad4455aedf4d66f8d94aa9f91542bf2a6766f0669cf91058f82c0ed", - "value": "4" + "id": "0xba33c3291e8547a7ee8c971c786ffa720d3df52650e5ff493be10d52c86688d9", + "value": "6" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0xdfa6c182e56bdcafb49a262da0da5ed17a58b8d53e9e4378baebc71748b5b3dc", - "value": "6" + "id": "0xc331b92ab20dd4a424b17a2c0bf507b935a92f84caee9b6f9717a61dc356607c", + "value": "2" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } } @@ -1461,66 +1461,66 @@ Response: { { "contents": { "json": { - "id": "0x1cf95cbbb66d52398519dbe561c026c8b2f8f3ca58294f162ad9a1f2957d6035", - "value": "3" + "id": "0x4f263537d7fe5e33e686f35580d88127cf67ca98fe3cce7dd910635eba391586", + "value": "4" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x20f00cdc31f4b422ecda21ace92ea2ade64d9a5aa38c03cf526a7f67836deff0", - "value": "2" + "id": "0x5941bc00a228a02d0db39d77f0cf61e36dbe9a1013f273e9ed0ee02eb3259160", + "value": "5" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x27204d98aadcf334e4b1a4fa39208c260669339c83808e2eb04e7ad4b1ba01cd", - "value": "5" + "id": "0x620fc261f44d1a27f42d6c8bd9d95c22c781966926056c56e4274140ba02d1b6", + "value": "3" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x82ef8d537fb2fe2c4a35f50cec7d8e46a96ffa1e76f90a66144b3e247696d17d", + "id": "0xaed872c4119b75506c212811899e9414db6106e3f687222db8833062003fa46e", "value": "200" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x96a37c40cad4455aedf4d66f8d94aa9f91542bf2a6766f0669cf91058f82c0ed", - "value": "4" + "id": "0xba33c3291e8547a7ee8c971c786ffa720d3df52650e5ff493be10d52c86688d9", + "value": "6" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0xdfa6c182e56bdcafb49a262da0da5ed17a58b8d53e9e4378baebc71748b5b3dc", - "value": "6" + "id": "0xc331b92ab20dd4a424b17a2c0bf507b935a92f84caee9b6f9717a61dc356607c", + "value": "2" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } } @@ -1536,66 +1536,66 @@ Response: { { "contents": { "json": { - "id": "0x1cf95cbbb66d52398519dbe561c026c8b2f8f3ca58294f162ad9a1f2957d6035", - "value": "3" + "id": "0x4f263537d7fe5e33e686f35580d88127cf67ca98fe3cce7dd910635eba391586", + "value": "4" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x20f00cdc31f4b422ecda21ace92ea2ade64d9a5aa38c03cf526a7f67836deff0", - "value": "2" + "id": "0x5941bc00a228a02d0db39d77f0cf61e36dbe9a1013f273e9ed0ee02eb3259160", + "value": "5" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x27204d98aadcf334e4b1a4fa39208c260669339c83808e2eb04e7ad4b1ba01cd", - "value": "5" + "id": "0x620fc261f44d1a27f42d6c8bd9d95c22c781966926056c56e4274140ba02d1b6", + "value": "3" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x82ef8d537fb2fe2c4a35f50cec7d8e46a96ffa1e76f90a66144b3e247696d17d", + "id": "0xaed872c4119b75506c212811899e9414db6106e3f687222db8833062003fa46e", "value": "200" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x96a37c40cad4455aedf4d66f8d94aa9f91542bf2a6766f0669cf91058f82c0ed", - "value": "4" + "id": "0xba33c3291e8547a7ee8c971c786ffa720d3df52650e5ff493be10d52c86688d9", + "value": "6" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0xdfa6c182e56bdcafb49a262da0da5ed17a58b8d53e9e4378baebc71748b5b3dc", - "value": "6" + "id": "0xc331b92ab20dd4a424b17a2c0bf507b935a92f84caee9b6f9717a61dc356607c", + "value": "2" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } } @@ -1609,66 +1609,66 @@ Response: { { "contents": { "json": { - "id": "0x1cf95cbbb66d52398519dbe561c026c8b2f8f3ca58294f162ad9a1f2957d6035", - "value": "3" + "id": "0x4f263537d7fe5e33e686f35580d88127cf67ca98fe3cce7dd910635eba391586", + "value": "4" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x20f00cdc31f4b422ecda21ace92ea2ade64d9a5aa38c03cf526a7f67836deff0", - "value": "2" + "id": "0x5941bc00a228a02d0db39d77f0cf61e36dbe9a1013f273e9ed0ee02eb3259160", + "value": "5" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x27204d98aadcf334e4b1a4fa39208c260669339c83808e2eb04e7ad4b1ba01cd", - "value": "5" + "id": "0x620fc261f44d1a27f42d6c8bd9d95c22c781966926056c56e4274140ba02d1b6", + "value": "3" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x82ef8d537fb2fe2c4a35f50cec7d8e46a96ffa1e76f90a66144b3e247696d17d", + "id": "0xaed872c4119b75506c212811899e9414db6106e3f687222db8833062003fa46e", "value": "200" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0x96a37c40cad4455aedf4d66f8d94aa9f91542bf2a6766f0669cf91058f82c0ed", - "value": "4" + "id": "0xba33c3291e8547a7ee8c971c786ffa720d3df52650e5ff493be10d52c86688d9", + "value": "6" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } }, { "contents": { "json": { - "id": "0xdfa6c182e56bdcafb49a262da0da5ed17a58b8d53e9e4378baebc71748b5b3dc", - "value": "6" + "id": "0xc331b92ab20dd4a424b17a2c0bf507b935a92f84caee9b6f9717a61dc356607c", + "value": "2" }, "type": { - "repr": "0x54c66a0373d27370da1294a4635920f2f8f3b09e1befe9de0d5602bbbbd4d1a7::M1::Object" + "repr": "0xfc270c987b7201d57da23ca7c3f431b2363860e19bb32efae81175586340241d::M1::Object" } } } diff --git a/crates/iota-graphql-e2e-tests/tests/epoch/chain_identifier.exp b/crates/iota-graphql-e2e-tests/tests/epoch/chain_identifier.exp index c150dc82e61..5053dbae825 100644 --- a/crates/iota-graphql-e2e-tests/tests/epoch/chain_identifier.exp +++ b/crates/iota-graphql-e2e-tests/tests/epoch/chain_identifier.exp @@ -11,6 +11,6 @@ task 2, lines 10-13: //# run-graphql Response: { "data": { - "chainIdentifier": "e1d5137d" + "chainIdentifier": "e50daeb7" } } diff --git a/crates/iota-graphql-e2e-tests/tests/epoch/epoch.exp b/crates/iota-graphql-e2e-tests/tests/epoch/epoch.exp index 9001cbd3bb2..9877e3587b3 100644 --- a/crates/iota-graphql-e2e-tests/tests/epoch/epoch.exp +++ b/crates/iota-graphql-e2e-tests/tests/epoch/epoch.exp @@ -21,11 +21,11 @@ gas summary: computation_cost: 1000000, storage_cost: 1976000, storage_rebate: task 4, lines 17-19: //# run 0x3::iota_system::request_add_stake --args object(0x5) object(3,0) @validator_0 --sender C -events: Event { package_id: iota_system, transaction_module: Identifier("iota_system"), sender: C, type_: StructTag { address: iota_system, module: Identifier("validator"), name: Identifier("StakingRequestEvent"), type_params: [] }, contents: [171, 56, 174, 116, 116, 231, 90, 122, 148, 80, 189, 213, 3, 8, 47, 190, 80, 171, 87, 32, 84, 9, 231, 203, 82, 3, 186, 181, 58, 235, 194, 1, 175, 163, 158, 79, 0, 218, 226, 120, 249, 119, 199, 198, 147, 10, 94, 44, 118, 232, 93, 23, 165, 38, 215, 36, 187, 206, 15, 184, 31, 176, 125, 76, 140, 202, 78, 28, 224, 186, 89, 4, 206, 166, 29, 249, 36, 45, 162, 247, 210, 158, 62, 243, 40, 251, 126, 192, 124, 8, 107, 59, 244, 124, 166, 26, 1, 0, 0, 0, 0, 0, 0, 0, 0, 228, 11, 84, 2, 0, 0, 0] } +events: Event { package_id: iota_system, transaction_module: Identifier("iota_system"), sender: C, type_: StructTag { address: iota_system, module: Identifier("validator"), name: Identifier("StakingRequestEvent"), type_params: [] }, contents: [135, 213, 224, 32, 91, 207, 0, 187, 34, 183, 14, 41, 167, 78, 77, 75, 138, 89, 173, 167, 170, 11, 38, 100, 45, 178, 245, 162, 113, 72, 177, 240, 175, 163, 158, 79, 0, 218, 226, 120, 249, 119, 199, 198, 147, 10, 94, 44, 118, 232, 93, 23, 165, 38, 215, 36, 187, 206, 15, 184, 31, 176, 125, 76, 140, 202, 78, 28, 224, 186, 89, 4, 206, 166, 29, 249, 36, 45, 162, 247, 210, 158, 62, 243, 40, 251, 126, 192, 124, 8, 107, 59, 244, 124, 166, 26, 1, 0, 0, 0, 0, 0, 0, 0, 0, 228, 11, 84, 2, 0, 0, 0] } created: object(4,0) mutated: object(_), 0x0000000000000000000000000000000000000000000000000000000000000005, object(0,0) deleted: object(3,0) -gas summary: computation_cost: 1000000, storage_cost: 14561600, storage_rebate: 1976000, non_refundable_storage_fee: 0 +gas summary: computation_cost: 1000000, storage_cost: 14523600, storage_rebate: 1976000, non_refundable_storage_fee: 0 task 5, line 20: //# create-checkpoint @@ -67,11 +67,11 @@ Response: { ] }, "validatorCandidatesSize": 0, - "inactivePoolsId": "0xa0ca410cb152a8d20832f3009367a5e33c1d8c3c20d146d7c6b749952e6b92ec" + "inactivePoolsId": "0x847b4f25419bcc012e269b2586a54b663d563de25024075481eb96e3ee8c3e0d" }, "totalGasFees": "1000000", "totalStakeRewards": "767000000000000", - "fundSize": "14561600", + "fundSize": "14523600", "fundInflow": "1976000", "fundOutflow": "988000", "netInflow": "988000", @@ -81,7 +81,7 @@ Response: { "kind": { "__typename": "ProgrammableTransactionBlock" }, - "digest": "4SwJFCerfaDJbFof2RVhiGmbbAjiiYA2nyurwzaF7NoK" + "digest": "93Nc7AV6A8XVKLh2r9VPCjAQwoVbuiEGSqUwGBCAKee5" }, { "kind": { diff --git a/crates/iota-graphql-e2e-tests/tests/epoch/system_state.exp b/crates/iota-graphql-e2e-tests/tests/epoch/system_state.exp index cc9b2e4c516..37638f48051 100644 --- a/crates/iota-graphql-e2e-tests/tests/epoch/system_state.exp +++ b/crates/iota-graphql-e2e-tests/tests/epoch/system_state.exp @@ -21,11 +21,11 @@ gas summary: computation_cost: 1000000, storage_cost: 1976000, storage_rebate: task 4, line 19: //# run 0x3::iota_system::request_add_stake --args object(0x5) object(3,0) @validator_0 --sender C -events: Event { package_id: iota_system, transaction_module: Identifier("iota_system"), sender: C, type_: StructTag { address: iota_system, module: Identifier("validator"), name: Identifier("StakingRequestEvent"), type_params: [] }, contents: [238, 153, 37, 48, 37, 251, 65, 114, 78, 217, 166, 206, 113, 249, 11, 156, 146, 124, 75, 213, 236, 255, 221, 178, 144, 192, 67, 121, 55, 3, 90, 248, 175, 163, 158, 79, 0, 218, 226, 120, 249, 119, 199, 198, 147, 10, 94, 44, 118, 232, 93, 23, 165, 38, 215, 36, 187, 206, 15, 184, 31, 176, 125, 76, 140, 202, 78, 28, 224, 186, 89, 4, 206, 166, 29, 249, 36, 45, 162, 247, 210, 158, 62, 243, 40, 251, 126, 192, 124, 8, 107, 59, 244, 124, 166, 26, 1, 0, 0, 0, 0, 0, 0, 0, 0, 228, 11, 84, 2, 0, 0, 0] } +events: Event { package_id: iota_system, transaction_module: Identifier("iota_system"), sender: C, type_: StructTag { address: iota_system, module: Identifier("validator"), name: Identifier("StakingRequestEvent"), type_params: [] }, contents: [205, 123, 84, 147, 81, 17, 130, 7, 90, 160, 180, 5, 78, 14, 89, 255, 128, 163, 195, 96, 66, 172, 246, 192, 149, 249, 164, 137, 55, 137, 167, 163, 175, 163, 158, 79, 0, 218, 226, 120, 249, 119, 199, 198, 147, 10, 94, 44, 118, 232, 93, 23, 165, 38, 215, 36, 187, 206, 15, 184, 31, 176, 125, 76, 140, 202, 78, 28, 224, 186, 89, 4, 206, 166, 29, 249, 36, 45, 162, 247, 210, 158, 62, 243, 40, 251, 126, 192, 124, 8, 107, 59, 244, 124, 166, 26, 1, 0, 0, 0, 0, 0, 0, 0, 0, 228, 11, 84, 2, 0, 0, 0] } created: object(4,0) mutated: object(_), 0x0000000000000000000000000000000000000000000000000000000000000005, object(0,0) deleted: object(3,0) -gas summary: computation_cost: 1000000, storage_cost: 14561600, storage_rebate: 1976000, non_refundable_storage_fee: 0 +gas summary: computation_cost: 1000000, storage_cost: 14523600, storage_rebate: 1976000, non_refundable_storage_fee: 0 task 5, line 21: //# create-checkpoint @@ -61,11 +61,11 @@ Epoch advanced: 3 task 12, line 37: //# run 0x3::iota_system::request_withdraw_stake --args object(0x5) object(4,0) --sender C -events: Event { package_id: iota_system, transaction_module: Identifier("iota_system"), sender: C, type_: StructTag { address: iota_system, module: Identifier("validator"), name: Identifier("UnstakingRequestEvent"), type_params: [] }, contents: [238, 153, 37, 48, 37, 251, 65, 114, 78, 217, 166, 206, 113, 249, 11, 156, 146, 124, 75, 213, 236, 255, 221, 178, 144, 192, 67, 121, 55, 3, 90, 248, 175, 163, 158, 79, 0, 218, 226, 120, 249, 119, 199, 198, 147, 10, 94, 44, 118, 232, 93, 23, 165, 38, 215, 36, 187, 206, 15, 184, 31, 176, 125, 76, 140, 202, 78, 28, 224, 186, 89, 4, 206, 166, 29, 249, 36, 45, 162, 247, 210, 158, 62, 243, 40, 251, 126, 192, 124, 8, 107, 59, 244, 124, 166, 26, 2, 0, 0, 0, 0, 0, 0, 0, 4, 0, 0, 0, 0, 0, 0, 0, 0, 228, 11, 84, 2, 0, 0, 0, 12, 33, 189, 38, 1, 0, 0, 0] } +events: Event { package_id: iota_system, transaction_module: Identifier("iota_system"), sender: C, type_: StructTag { address: iota_system, module: Identifier("validator"), name: Identifier("UnstakingRequestEvent"), type_params: [] }, contents: [205, 123, 84, 147, 81, 17, 130, 7, 90, 160, 180, 5, 78, 14, 89, 255, 128, 163, 195, 96, 66, 172, 246, 192, 149, 249, 164, 137, 55, 137, 167, 163, 175, 163, 158, 79, 0, 218, 226, 120, 249, 119, 199, 198, 147, 10, 94, 44, 118, 232, 93, 23, 165, 38, 215, 36, 187, 206, 15, 184, 31, 176, 125, 76, 140, 202, 78, 28, 224, 186, 89, 4, 206, 166, 29, 249, 36, 45, 162, 247, 210, 158, 62, 243, 40, 251, 126, 192, 124, 8, 107, 59, 244, 124, 166, 26, 2, 0, 0, 0, 0, 0, 0, 0, 4, 0, 0, 0, 0, 0, 0, 0, 0, 228, 11, 84, 2, 0, 0, 0, 12, 33, 189, 38, 1, 0, 0, 0] } created: object(12,0) mutated: object(_), 0x0000000000000000000000000000000000000000000000000000000000000005, object(0,0) deleted: object(4,0) -gas summary: computation_cost: 1000000, storage_cost: 14257600, storage_rebate: 14561600, non_refundable_storage_fee: 0 +gas summary: computation_cost: 1000000, storage_cost: 14219600, storage_rebate: 14523600, non_refundable_storage_fee: 0 task 13, line 39: //# create-checkpoint @@ -97,9 +97,9 @@ Response: { "data": { "epoch": { "epochId": 4, - "systemStateVersion": 2, + "systemStateVersion": 1, "storageFund": { - "totalObjectStorageRebates": "15245600", + "totalObjectStorageRebates": "15207600", "nonRefundableBalance": "0" } } @@ -112,9 +112,9 @@ Response: { "data": { "epoch": { "epochId": 3, - "systemStateVersion": 2, + "systemStateVersion": 1, "storageFund": { - "totalObjectStorageRebates": "15549600", + "totalObjectStorageRebates": "15511600", "nonRefundableBalance": "0" } } @@ -127,9 +127,9 @@ Response: { "data": { "epoch": { "epochId": 2, - "systemStateVersion": 2, + "systemStateVersion": 1, "storageFund": { - "totalObjectStorageRebates": "14561600", + "totalObjectStorageRebates": "14523600", "nonRefundableBalance": "0" } } @@ -142,9 +142,9 @@ Response: { "data": { "epoch": { "epochId": 1, - "systemStateVersion": 2, + "systemStateVersion": 1, "storageFund": { - "totalObjectStorageRebates": "14561600", + "totalObjectStorageRebates": "14523600", "nonRefundableBalance": "0" } } @@ -157,9 +157,9 @@ Response: { "data": { "epoch": { "epochId": 4, - "systemStateVersion": 2, + "systemStateVersion": 1, "storageFund": { - "totalObjectStorageRebates": "15245600", + "totalObjectStorageRebates": "15207600", "nonRefundableBalance": "0" } } diff --git a/crates/iota-graphql-e2e-tests/tests/errors/clever_errors.exp b/crates/iota-graphql-e2e-tests/tests/errors/clever_errors.exp index bd9c13a8314..bc31e0d2577 100644 --- a/crates/iota-graphql-e2e-tests/tests/errors/clever_errors.exp +++ b/crates/iota-graphql-e2e-tests/tests/errors/clever_errors.exp @@ -77,67 +77,67 @@ Response: { { "effects": { "status": "FAILURE", - "errors": "Error in 1st command, from '0x89423a90eca23c8d14ab44895f6f8b49e1e692e2e7ea8a9adb677e982cff2a99::m::callU8' (line 30), abort 'ImAU8': 0" + "errors": "Error in 1st command, from '0x272f89312434a7e0b32617380778c571431e5b379e2ad4cbd1660981e617300e::m::callU8' (line 30), abort 'ImAU8': 0" } }, { "effects": { "status": "FAILURE", - "errors": "Error in 1st command, from '0x89423a90eca23c8d14ab44895f6f8b49e1e692e2e7ea8a9adb677e982cff2a99::m::callU16' (line 33), abort 'ImAU16': 1" + "errors": "Error in 1st command, from '0x272f89312434a7e0b32617380778c571431e5b379e2ad4cbd1660981e617300e::m::callU16' (line 33), abort 'ImAU16': 1" } }, { "effects": { "status": "FAILURE", - "errors": "Error in 1st command, from '0x89423a90eca23c8d14ab44895f6f8b49e1e692e2e7ea8a9adb677e982cff2a99::m::callU32' (line 36), abort 'ImAU32': 2" + "errors": "Error in 1st command, from '0x272f89312434a7e0b32617380778c571431e5b379e2ad4cbd1660981e617300e::m::callU32' (line 36), abort 'ImAU32': 2" } }, { "effects": { "status": "FAILURE", - "errors": "Error in 1st command, from '0x89423a90eca23c8d14ab44895f6f8b49e1e692e2e7ea8a9adb677e982cff2a99::m::callU64' (line 39), abort 'ImAU64': 3" + "errors": "Error in 1st command, from '0x272f89312434a7e0b32617380778c571431e5b379e2ad4cbd1660981e617300e::m::callU64' (line 39), abort 'ImAU64': 3" } }, { "effects": { "status": "FAILURE", - "errors": "Error in 1st command, from '0x89423a90eca23c8d14ab44895f6f8b49e1e692e2e7ea8a9adb677e982cff2a99::m::callU128' (line 42), abort 'ImAU128': 4" + "errors": "Error in 1st command, from '0x272f89312434a7e0b32617380778c571431e5b379e2ad4cbd1660981e617300e::m::callU128' (line 42), abort 'ImAU128': 4" } }, { "effects": { "status": "FAILURE", - "errors": "Error in 1st command, from '0x89423a90eca23c8d14ab44895f6f8b49e1e692e2e7ea8a9adb677e982cff2a99::m::callU256' (line 45), abort 'ImAU256': 5" + "errors": "Error in 1st command, from '0x272f89312434a7e0b32617380778c571431e5b379e2ad4cbd1660981e617300e::m::callU256' (line 45), abort 'ImAU256': 5" } }, { "effects": { "status": "FAILURE", - "errors": "Error in 1st command, from '0x89423a90eca23c8d14ab44895f6f8b49e1e692e2e7ea8a9adb677e982cff2a99::m::callAddress' (line 48), abort 'ImAnAddress': 0x0000000000000000000000000000000000000000000000000000000000000006" + "errors": "Error in 1st command, from '0x272f89312434a7e0b32617380778c571431e5b379e2ad4cbd1660981e617300e::m::callAddress' (line 48), abort 'ImAnAddress': 0x0000000000000000000000000000000000000000000000000000000000000006" } }, { "effects": { "status": "FAILURE", - "errors": "Error in 1st command, from '0x89423a90eca23c8d14ab44895f6f8b49e1e692e2e7ea8a9adb677e982cff2a99::m::callString' (line 51), abort 'ImAString': This is a string" + "errors": "Error in 1st command, from '0x272f89312434a7e0b32617380778c571431e5b379e2ad4cbd1660981e617300e::m::callString' (line 51), abort 'ImAString': This is a string" } }, { "effects": { "status": "FAILURE", - "errors": "Error in 1st command, from '0x89423a90eca23c8d14ab44895f6f8b49e1e692e2e7ea8a9adb677e982cff2a99::m::callU64vec' (line 54), abort 'ImNotAString': BQEAAAAAAAAAAgAAAAAAAAADAAAAAAAAAAQAAAAAAAAABQAAAAAAAAA=" + "errors": "Error in 1st command, from '0x272f89312434a7e0b32617380778c571431e5b379e2ad4cbd1660981e617300e::m::callU64vec' (line 54), abort 'ImNotAString': BQEAAAAAAAAAAgAAAAAAAAADAAAAAAAAAAQAAAAAAAAABQAAAAAAAAA=" } }, { "effects": { "status": "FAILURE", - "errors": "Error in 1st command, from '0x89423a90eca23c8d14ab44895f6f8b49e1e692e2e7ea8a9adb677e982cff2a99::m::normalAbort' (instruction 1), abort code: 0" + "errors": "Error in 1st command, from '0x272f89312434a7e0b32617380778c571431e5b379e2ad4cbd1660981e617300e::m::normalAbort' (instruction 1), abort code: 0" } }, { "effects": { "status": "FAILURE", - "errors": "Error in 1st command, from '0x89423a90eca23c8d14ab44895f6f8b49e1e692e2e7ea8a9adb677e982cff2a99::m::assertLineNo' (line 60)" + "errors": "Error in 1st command, from '0x272f89312434a7e0b32617380778c571431e5b379e2ad4cbd1660981e617300e::m::assertLineNo' (line 60)" } } ] @@ -248,7 +248,7 @@ Response: { }, "errors": [ { - "message": "Internal error occurred while processing request: Error resolving Move location: Linkage not found for package: f4edd879a3a46dd7756ce940d92d10443b1e930ebfafc542ee488fb6d94c29fb", + "message": "Internal error occurred while processing request: Error resolving Move location: Linkage not found for package: 168dbb87a20484b73a83e5df7991f60e1eac7cb5d2bb7175ae45ce2d3ae3ea60", "locations": [ { "line": 6, @@ -264,7 +264,7 @@ Response: { ] }, { - "message": "Internal error occurred while processing request: Error resolving Move location: Linkage not found for package: f4edd879a3a46dd7756ce940d92d10443b1e930ebfafc542ee488fb6d94c29fb", + "message": "Internal error occurred while processing request: Error resolving Move location: Linkage not found for package: 168dbb87a20484b73a83e5df7991f60e1eac7cb5d2bb7175ae45ce2d3ae3ea60", "locations": [ { "line": 6, @@ -280,7 +280,7 @@ Response: { ] }, { - "message": "Internal error occurred while processing request: Error resolving Move location: Linkage not found for package: f4edd879a3a46dd7756ce940d92d10443b1e930ebfafc542ee488fb6d94c29fb", + "message": "Internal error occurred while processing request: Error resolving Move location: Linkage not found for package: 168dbb87a20484b73a83e5df7991f60e1eac7cb5d2bb7175ae45ce2d3ae3ea60", "locations": [ { "line": 6, @@ -296,7 +296,7 @@ Response: { ] }, { - "message": "Internal error occurred while processing request: Error resolving Move location: Linkage not found for package: f4edd879a3a46dd7756ce940d92d10443b1e930ebfafc542ee488fb6d94c29fb", + "message": "Internal error occurred while processing request: Error resolving Move location: Linkage not found for package: 168dbb87a20484b73a83e5df7991f60e1eac7cb5d2bb7175ae45ce2d3ae3ea60", "locations": [ { "line": 6, @@ -312,7 +312,7 @@ Response: { ] }, { - "message": "Internal error occurred while processing request: Error resolving Move location: Linkage not found for package: f4edd879a3a46dd7756ce940d92d10443b1e930ebfafc542ee488fb6d94c29fb", + "message": "Internal error occurred while processing request: Error resolving Move location: Linkage not found for package: 168dbb87a20484b73a83e5df7991f60e1eac7cb5d2bb7175ae45ce2d3ae3ea60", "locations": [ { "line": 6, @@ -328,7 +328,7 @@ Response: { ] }, { - "message": "Internal error occurred while processing request: Error resolving Move location: Linkage not found for package: f4edd879a3a46dd7756ce940d92d10443b1e930ebfafc542ee488fb6d94c29fb", + "message": "Internal error occurred while processing request: Error resolving Move location: Linkage not found for package: 168dbb87a20484b73a83e5df7991f60e1eac7cb5d2bb7175ae45ce2d3ae3ea60", "locations": [ { "line": 6, @@ -344,7 +344,7 @@ Response: { ] }, { - "message": "Internal error occurred while processing request: Error resolving Move location: Linkage not found for package: f4edd879a3a46dd7756ce940d92d10443b1e930ebfafc542ee488fb6d94c29fb", + "message": "Internal error occurred while processing request: Error resolving Move location: Linkage not found for package: 168dbb87a20484b73a83e5df7991f60e1eac7cb5d2bb7175ae45ce2d3ae3ea60", "locations": [ { "line": 6, @@ -360,7 +360,7 @@ Response: { ] }, { - "message": "Internal error occurred while processing request: Error resolving Move location: Linkage not found for package: f4edd879a3a46dd7756ce940d92d10443b1e930ebfafc542ee488fb6d94c29fb", + "message": "Internal error occurred while processing request: Error resolving Move location: Linkage not found for package: 168dbb87a20484b73a83e5df7991f60e1eac7cb5d2bb7175ae45ce2d3ae3ea60", "locations": [ { "line": 6, @@ -376,7 +376,7 @@ Response: { ] }, { - "message": "Internal error occurred while processing request: Error resolving Move location: Linkage not found for package: f4edd879a3a46dd7756ce940d92d10443b1e930ebfafc542ee488fb6d94c29fb", + "message": "Internal error occurred while processing request: Error resolving Move location: Linkage not found for package: 168dbb87a20484b73a83e5df7991f60e1eac7cb5d2bb7175ae45ce2d3ae3ea60", "locations": [ { "line": 6, diff --git a/crates/iota-graphql-e2e-tests/tests/errors/clever_errors_in_macros.exp b/crates/iota-graphql-e2e-tests/tests/errors/clever_errors_in_macros.exp index 2a1dad360a2..eb63fd74a73 100644 --- a/crates/iota-graphql-e2e-tests/tests/errors/clever_errors_in_macros.exp +++ b/crates/iota-graphql-e2e-tests/tests/errors/clever_errors_in_macros.exp @@ -37,19 +37,19 @@ Response: { { "effects": { "status": "FAILURE", - "errors": "Error in 1st command, from '0x232dca06e9cd0e6f2f6d5a3fbf1dae33e98e604f83bab179a2941b9829442fe5::m::t_a' (line 21)" + "errors": "Error in 1st command, from '0xf986879d81b7d0b4f49b825917bd6a5b38f9764b5d1aebc2186f279b2427f3d8::m::t_a' (line 21)" } }, { "effects": { "status": "FAILURE", - "errors": "Error in 1st command, from '0x232dca06e9cd0e6f2f6d5a3fbf1dae33e98e604f83bab179a2941b9829442fe5::m::t_calls_a' (line 24)" + "errors": "Error in 1st command, from '0xf986879d81b7d0b4f49b825917bd6a5b38f9764b5d1aebc2186f279b2427f3d8::m::t_calls_a' (line 24)" } }, { "effects": { "status": "FAILURE", - "errors": "Error in 1st command, from '0x232dca06e9cd0e6f2f6d5a3fbf1dae33e98e604f83bab179a2941b9829442fe5::m::t_const_assert' (line 10), abort 'EMsg': This is a string" + "errors": "Error in 1st command, from '0xf986879d81b7d0b4f49b825917bd6a5b38f9764b5d1aebc2186f279b2427f3d8::m::t_const_assert' (line 10), abort 'EMsg': This is a string" } } ] diff --git a/crates/iota-graphql-e2e-tests/tests/event_connection/event_connection.exp b/crates/iota-graphql-e2e-tests/tests/event_connection/event_connection.exp index 3bc37bd892e..f75860547fe 100644 --- a/crates/iota-graphql-e2e-tests/tests/event_connection/event_connection.exp +++ b/crates/iota-graphql-e2e-tests/tests/event_connection/event_connection.exp @@ -62,7 +62,7 @@ Response: { "name": "M1" }, "type": { - "repr": "0xbbc4ca6eb4699aae135eeaf9dc150a0d4aa62872e29f557ab7416f1eadcf434a::M1::EventA" + "repr": "0xd371fbe5cbff8564a9eaa134fddceda7f7b9ced168da92257226477c8e29ddcd::M1::EventA" }, "sender": { "address": "0x8cca4e1ce0ba5904cea61df9242da2f7d29e3ef328fb7ec07c086b3bf47ca61a" @@ -80,7 +80,7 @@ Response: { "name": "M1" }, "type": { - "repr": "0xbbc4ca6eb4699aae135eeaf9dc150a0d4aa62872e29f557ab7416f1eadcf434a::M1::EventB<0xbbc4ca6eb4699aae135eeaf9dc150a0d4aa62872e29f557ab7416f1eadcf434a::M1::Object>" + "repr": "0xd371fbe5cbff8564a9eaa134fddceda7f7b9ced168da92257226477c8e29ddcd::M1::EventB<0xd371fbe5cbff8564a9eaa134fddceda7f7b9ced168da92257226477c8e29ddcd::M1::Object>" }, "sender": { "address": "0x8cca4e1ce0ba5904cea61df9242da2f7d29e3ef328fb7ec07c086b3bf47ca61a" @@ -98,7 +98,7 @@ Response: { "name": "M2" }, "type": { - "repr": "0xbbc4ca6eb4699aae135eeaf9dc150a0d4aa62872e29f557ab7416f1eadcf434a::M2::EventA" + "repr": "0xd371fbe5cbff8564a9eaa134fddceda7f7b9ced168da92257226477c8e29ddcd::M2::EventA" }, "sender": { "address": "0x8cca4e1ce0ba5904cea61df9242da2f7d29e3ef328fb7ec07c086b3bf47ca61a" @@ -116,7 +116,7 @@ Response: { "name": "M2" }, "type": { - "repr": "0xbbc4ca6eb4699aae135eeaf9dc150a0d4aa62872e29f557ab7416f1eadcf434a::M2::EventB<0xbbc4ca6eb4699aae135eeaf9dc150a0d4aa62872e29f557ab7416f1eadcf434a::M2::Object>" + "repr": "0xd371fbe5cbff8564a9eaa134fddceda7f7b9ced168da92257226477c8e29ddcd::M2::EventB<0xd371fbe5cbff8564a9eaa134fddceda7f7b9ced168da92257226477c8e29ddcd::M2::Object>" }, "sender": { "address": "0x8cca4e1ce0ba5904cea61df9242da2f7d29e3ef328fb7ec07c086b3bf47ca61a" @@ -145,7 +145,7 @@ Response: { "name": "M1" }, "type": { - "repr": "0xbbc4ca6eb4699aae135eeaf9dc150a0d4aa62872e29f557ab7416f1eadcf434a::M1::EventA" + "repr": "0xd371fbe5cbff8564a9eaa134fddceda7f7b9ced168da92257226477c8e29ddcd::M1::EventA" }, "sender": { "address": "0x8cca4e1ce0ba5904cea61df9242da2f7d29e3ef328fb7ec07c086b3bf47ca61a" @@ -163,7 +163,7 @@ Response: { "name": "M1" }, "type": { - "repr": "0xbbc4ca6eb4699aae135eeaf9dc150a0d4aa62872e29f557ab7416f1eadcf434a::M1::EventB<0xbbc4ca6eb4699aae135eeaf9dc150a0d4aa62872e29f557ab7416f1eadcf434a::M1::Object>" + "repr": "0xd371fbe5cbff8564a9eaa134fddceda7f7b9ced168da92257226477c8e29ddcd::M1::EventB<0xd371fbe5cbff8564a9eaa134fddceda7f7b9ced168da92257226477c8e29ddcd::M1::Object>" }, "sender": { "address": "0x8cca4e1ce0ba5904cea61df9242da2f7d29e3ef328fb7ec07c086b3bf47ca61a" @@ -181,7 +181,7 @@ Response: { "name": "M2" }, "type": { - "repr": "0xbbc4ca6eb4699aae135eeaf9dc150a0d4aa62872e29f557ab7416f1eadcf434a::M2::EventA" + "repr": "0xd371fbe5cbff8564a9eaa134fddceda7f7b9ced168da92257226477c8e29ddcd::M2::EventA" }, "sender": { "address": "0x8cca4e1ce0ba5904cea61df9242da2f7d29e3ef328fb7ec07c086b3bf47ca61a" @@ -199,7 +199,7 @@ Response: { "name": "M2" }, "type": { - "repr": "0xbbc4ca6eb4699aae135eeaf9dc150a0d4aa62872e29f557ab7416f1eadcf434a::M2::EventB<0xbbc4ca6eb4699aae135eeaf9dc150a0d4aa62872e29f557ab7416f1eadcf434a::M2::Object>" + "repr": "0xd371fbe5cbff8564a9eaa134fddceda7f7b9ced168da92257226477c8e29ddcd::M2::EventB<0xd371fbe5cbff8564a9eaa134fddceda7f7b9ced168da92257226477c8e29ddcd::M2::Object>" }, "sender": { "address": "0x8cca4e1ce0ba5904cea61df9242da2f7d29e3ef328fb7ec07c086b3bf47ca61a" @@ -228,7 +228,7 @@ Response: { "name": "M1" }, "type": { - "repr": "0xbbc4ca6eb4699aae135eeaf9dc150a0d4aa62872e29f557ab7416f1eadcf434a::M1::EventA" + "repr": "0xd371fbe5cbff8564a9eaa134fddceda7f7b9ced168da92257226477c8e29ddcd::M1::EventA" }, "sender": { "address": "0x8cca4e1ce0ba5904cea61df9242da2f7d29e3ef328fb7ec07c086b3bf47ca61a" @@ -246,7 +246,7 @@ Response: { "name": "M1" }, "type": { - "repr": "0xbbc4ca6eb4699aae135eeaf9dc150a0d4aa62872e29f557ab7416f1eadcf434a::M1::EventB<0xbbc4ca6eb4699aae135eeaf9dc150a0d4aa62872e29f557ab7416f1eadcf434a::M1::Object>" + "repr": "0xd371fbe5cbff8564a9eaa134fddceda7f7b9ced168da92257226477c8e29ddcd::M1::EventB<0xd371fbe5cbff8564a9eaa134fddceda7f7b9ced168da92257226477c8e29ddcd::M1::Object>" }, "sender": { "address": "0x8cca4e1ce0ba5904cea61df9242da2f7d29e3ef328fb7ec07c086b3bf47ca61a" @@ -275,7 +275,7 @@ Response: { "name": "M1" }, "type": { - "repr": "0xbbc4ca6eb4699aae135eeaf9dc150a0d4aa62872e29f557ab7416f1eadcf434a::M1::EventA" + "repr": "0xd371fbe5cbff8564a9eaa134fddceda7f7b9ced168da92257226477c8e29ddcd::M1::EventA" }, "sender": { "address": "0x8cca4e1ce0ba5904cea61df9242da2f7d29e3ef328fb7ec07c086b3bf47ca61a" @@ -304,7 +304,7 @@ Response: { "name": "M1" }, "type": { - "repr": "0xbbc4ca6eb4699aae135eeaf9dc150a0d4aa62872e29f557ab7416f1eadcf434a::M1::EventB<0xbbc4ca6eb4699aae135eeaf9dc150a0d4aa62872e29f557ab7416f1eadcf434a::M1::Object>" + "repr": "0xd371fbe5cbff8564a9eaa134fddceda7f7b9ced168da92257226477c8e29ddcd::M1::EventB<0xd371fbe5cbff8564a9eaa134fddceda7f7b9ced168da92257226477c8e29ddcd::M1::Object>" }, "sender": { "address": "0x8cca4e1ce0ba5904cea61df9242da2f7d29e3ef328fb7ec07c086b3bf47ca61a" diff --git a/crates/iota-graphql-e2e-tests/tests/event_connection/nested_emit_event.exp b/crates/iota-graphql-e2e-tests/tests/event_connection/nested_emit_event.exp index af318745132..00f41ed55ae 100644 --- a/crates/iota-graphql-e2e-tests/tests/event_connection/nested_emit_event.exp +++ b/crates/iota-graphql-e2e-tests/tests/event_connection/nested_emit_event.exp @@ -30,7 +30,7 @@ Response: { "name": "M3" }, "type": { - "repr": "0xe97fc5bb4773ce63b9891018d2859918153e40e7db15133fd25cd170734cef6f::M1::EventA" + "repr": "0xd2f29f7361ce369a36924576b23440a0a3b81ab975c44c7e837e6d74ff0e4a51::M1::EventA" }, "sender": { "address": "0x8cca4e1ce0ba5904cea61df9242da2f7d29e3ef328fb7ec07c086b3bf47ca61a" @@ -56,7 +56,7 @@ Response: { "name": "M3" }, "type": { - "repr": "0xe97fc5bb4773ce63b9891018d2859918153e40e7db15133fd25cd170734cef6f::M1::EventA" + "repr": "0xd2f29f7361ce369a36924576b23440a0a3b81ab975c44c7e837e6d74ff0e4a51::M1::EventA" }, "sender": { "address": "0x8cca4e1ce0ba5904cea61df9242da2f7d29e3ef328fb7ec07c086b3bf47ca61a" @@ -102,7 +102,7 @@ Response: { "name": "M3" }, "type": { - "repr": "0xe97fc5bb4773ce63b9891018d2859918153e40e7db15133fd25cd170734cef6f::M1::EventA" + "repr": "0xd2f29f7361ce369a36924576b23440a0a3b81ab975c44c7e837e6d74ff0e4a51::M1::EventA" }, "sender": { "address": "0x8cca4e1ce0ba5904cea61df9242da2f7d29e3ef328fb7ec07c086b3bf47ca61a" diff --git a/crates/iota-graphql-e2e-tests/tests/event_connection/no_filter.exp b/crates/iota-graphql-e2e-tests/tests/event_connection/no_filter.exp index 6ea0b3c6b60..17d9efd6aa0 100644 --- a/crates/iota-graphql-e2e-tests/tests/event_connection/no_filter.exp +++ b/crates/iota-graphql-e2e-tests/tests/event_connection/no_filter.exp @@ -33,12 +33,12 @@ Response: { "nodes": [ { "json": { - "id": "0x2b91473159957c052b1a93d9c1376ab0d91b605c8316be4b2662e9cc336d083e" + "id": "0x9a734cbfbfeed77d0efa6574430f2ebae3c84c16a81f4cf11e4fa101ed54baa3" } }, { "json": { - "id": "0x2b91473159957c052b1a93d9c1376ab0d91b605c8316be4b2662e9cc336d083e", + "id": "0x9a734cbfbfeed77d0efa6574430f2ebae3c84c16a81f4cf11e4fa101ed54baa3", "version": 1, "fields": { "contents": [ diff --git a/crates/iota-graphql-e2e-tests/tests/event_connection/pagination.exp b/crates/iota-graphql-e2e-tests/tests/event_connection/pagination.exp index 3e71075225a..0c54da135ec 100644 --- a/crates/iota-graphql-e2e-tests/tests/event_connection/pagination.exp +++ b/crates/iota-graphql-e2e-tests/tests/event_connection/pagination.exp @@ -42,7 +42,7 @@ Response: { "name": "M1" }, "type": { - "repr": "0xcbb55f60a0de682701cda4af908db58c79fdc776113e863da4c5d1ddd0b8e5cf::M1::EventA" + "repr": "0xc9397d10a3be916a77114efa9fdabf14e54811b454e4798357964ce380726952::M1::EventA" }, "sender": { "address": "0x8cca4e1ce0ba5904cea61df9242da2f7d29e3ef328fb7ec07c086b3bf47ca61a" @@ -60,7 +60,7 @@ Response: { "name": "M1" }, "type": { - "repr": "0xcbb55f60a0de682701cda4af908db58c79fdc776113e863da4c5d1ddd0b8e5cf::M1::EventA" + "repr": "0xc9397d10a3be916a77114efa9fdabf14e54811b454e4798357964ce380726952::M1::EventA" }, "sender": { "address": "0x8cca4e1ce0ba5904cea61df9242da2f7d29e3ef328fb7ec07c086b3bf47ca61a" @@ -78,7 +78,7 @@ Response: { "name": "M1" }, "type": { - "repr": "0xcbb55f60a0de682701cda4af908db58c79fdc776113e863da4c5d1ddd0b8e5cf::M1::EventA" + "repr": "0xc9397d10a3be916a77114efa9fdabf14e54811b454e4798357964ce380726952::M1::EventA" }, "sender": { "address": "0x8cca4e1ce0ba5904cea61df9242da2f7d29e3ef328fb7ec07c086b3bf47ca61a" @@ -111,7 +111,7 @@ Response: { "name": "M1" }, "type": { - "repr": "0xcbb55f60a0de682701cda4af908db58c79fdc776113e863da4c5d1ddd0b8e5cf::M1::EventA" + "repr": "0xc9397d10a3be916a77114efa9fdabf14e54811b454e4798357964ce380726952::M1::EventA" }, "sender": { "address": "0x8cca4e1ce0ba5904cea61df9242da2f7d29e3ef328fb7ec07c086b3bf47ca61a" @@ -129,7 +129,7 @@ Response: { "name": "M1" }, "type": { - "repr": "0xcbb55f60a0de682701cda4af908db58c79fdc776113e863da4c5d1ddd0b8e5cf::M1::EventA" + "repr": "0xc9397d10a3be916a77114efa9fdabf14e54811b454e4798357964ce380726952::M1::EventA" }, "sender": { "address": "0x8cca4e1ce0ba5904cea61df9242da2f7d29e3ef328fb7ec07c086b3bf47ca61a" @@ -162,7 +162,7 @@ Response: { "name": "M1" }, "type": { - "repr": "0xcbb55f60a0de682701cda4af908db58c79fdc776113e863da4c5d1ddd0b8e5cf::M1::EventA" + "repr": "0xc9397d10a3be916a77114efa9fdabf14e54811b454e4798357964ce380726952::M1::EventA" }, "sender": { "address": "0x8cca4e1ce0ba5904cea61df9242da2f7d29e3ef328fb7ec07c086b3bf47ca61a" @@ -180,7 +180,7 @@ Response: { "name": "M1" }, "type": { - "repr": "0xcbb55f60a0de682701cda4af908db58c79fdc776113e863da4c5d1ddd0b8e5cf::M1::EventA" + "repr": "0xc9397d10a3be916a77114efa9fdabf14e54811b454e4798357964ce380726952::M1::EventA" }, "sender": { "address": "0x8cca4e1ce0ba5904cea61df9242da2f7d29e3ef328fb7ec07c086b3bf47ca61a" @@ -213,7 +213,7 @@ Response: { "name": "M1" }, "type": { - "repr": "0xcbb55f60a0de682701cda4af908db58c79fdc776113e863da4c5d1ddd0b8e5cf::M1::EventA" + "repr": "0xc9397d10a3be916a77114efa9fdabf14e54811b454e4798357964ce380726952::M1::EventA" }, "sender": { "address": "0x8cca4e1ce0ba5904cea61df9242da2f7d29e3ef328fb7ec07c086b3bf47ca61a" @@ -231,7 +231,7 @@ Response: { "name": "M1" }, "type": { - "repr": "0xcbb55f60a0de682701cda4af908db58c79fdc776113e863da4c5d1ddd0b8e5cf::M1::EventA" + "repr": "0xc9397d10a3be916a77114efa9fdabf14e54811b454e4798357964ce380726952::M1::EventA" }, "sender": { "address": "0x8cca4e1ce0ba5904cea61df9242da2f7d29e3ef328fb7ec07c086b3bf47ca61a" diff --git a/crates/iota-graphql-e2e-tests/tests/event_connection/tx_digest.exp b/crates/iota-graphql-e2e-tests/tests/event_connection/tx_digest.exp index 68b49a7f84e..48cb46c959c 100644 --- a/crates/iota-graphql-e2e-tests/tests/event_connection/tx_digest.exp +++ b/crates/iota-graphql-e2e-tests/tests/event_connection/tx_digest.exp @@ -37,19 +37,19 @@ Response: { "transactionBlocks": { "nodes": [ { - "digest": "8twBu7kvzDbfSLjpBJ2GbDpfARJpwkdVCywZJqQCc3Eu" + "digest": "b5R95kKQ5woMzx3Qv8GjKKG7JZZLLsg1DAFkuKULx7V" }, { - "digest": "GaaiNS8XyGWps9PtJ2ApYExhGVZrc7wPuzbYezy5c8WU" + "digest": "ErvTYR6mPWiZYePpStGyH6Nw8ckgpSzrPgGw7Vkdw6JK" }, { - "digest": "3BB3PxmDSRahQe17BJZFE4tidPq4L9nGzabs7DF1jqvD" + "digest": "FN7PLE3HgySgBBAoFSxAjnoDk6iuXBoREtCwT8VHErcT" }, { - "digest": "8kPLT27dhuva4i5SCqEZFFsBuBD1NZuYcMZnVBEPkhnU" + "digest": "3KCnLq3sQtjsuxxQahpwYzGE5SwKbYFM4qXAjKDjc2QB" }, { - "digest": "5NrZrqgHFvE75nD5DmpyWgbr1rjPNwFqh86cn2v9eB7V" + "digest": "F3rgBaRQZ6Fjyw1YS2LFjyc4WzbTAKWzev2atucRxMGa" } ] } @@ -61,24 +61,7 @@ task 7, lines 46-58: Response: { "data": { "events": { - "edges": [ - { - "cursor": "eyJ0eCI6MywiZSI6MCwiYyI6MX0", - "node": { - "json": { - "new_value": "2" - } - } - }, - { - "cursor": "eyJ0eCI6MywiZSI6MSwiYyI6MX0", - "node": { - "json": { - "new_value": "3" - } - } - } - ] + "edges": [] } } } @@ -108,24 +91,7 @@ task 10, lines 93-105: Response: { "data": { "events": { - "edges": [ - { - "cursor": "eyJ0eCI6NCwiZSI6MCwiYyI6MX0", - "node": { - "json": { - "new_value": "4" - } - } - }, - { - "cursor": "eyJ0eCI6NCwiZSI6MSwiYyI6MX0", - "node": { - "json": { - "new_value": "5" - } - } - } - ] + "edges": [] } } } @@ -135,16 +101,7 @@ task 11, lines 107-119: Response: { "data": { "events": { - "edges": [ - { - "cursor": "eyJ0eCI6NCwiZSI6MSwiYyI6MX0", - "node": { - "json": { - "new_value": "5" - } - } - } - ] + "edges": [] } } } @@ -154,24 +111,7 @@ task 12, lines 122-134: Response: { "data": { "events": { - "edges": [ - { - "cursor": "eyJ0eCI6MywiZSI6MCwiYyI6MX0", - "node": { - "json": { - "new_value": "2" - } - } - }, - { - "cursor": "eyJ0eCI6MywiZSI6MSwiYyI6MX0", - "node": { - "json": { - "new_value": "3" - } - } - } - ] + "edges": [] } } } @@ -181,16 +121,7 @@ task 13, lines 136-149: Response: { "data": { "events": { - "edges": [ - { - "cursor": "eyJ0eCI6MywiZSI6MCwiYyI6MX0", - "node": { - "json": { - "new_value": "2" - } - } - } - ] + "edges": [] } } } @@ -210,24 +141,7 @@ task 15, lines 169-181: Response: { "data": { "events": { - "edges": [ - { - "cursor": "eyJ0eCI6NCwiZSI6MCwiYyI6MX0", - "node": { - "json": { - "new_value": "4" - } - } - }, - { - "cursor": "eyJ0eCI6NCwiZSI6MSwiYyI6MX0", - "node": { - "json": { - "new_value": "5" - } - } - } - ] + "edges": [] } } } @@ -237,16 +151,7 @@ task 16, lines 183-195: Response: { "data": { "events": { - "edges": [ - { - "cursor": "eyJ0eCI6NCwiZSI6MCwiYyI6MX0", - "node": { - "json": { - "new_value": "4" - } - } - } - ] + "edges": [] } } } @@ -256,24 +161,7 @@ task 17, lines 197-210: Response: { "data": { "events": { - "edges": [ - { - "cursor": "eyJ0eCI6MywiZSI6MCwiYyI6MX0", - "node": { - "json": { - "new_value": "2" - } - } - }, - { - "cursor": "eyJ0eCI6MywiZSI6MSwiYyI6MX0", - "node": { - "json": { - "new_value": "3" - } - } - } - ] + "edges": [] } } } @@ -283,24 +171,7 @@ task 18, lines 212-225: Response: { "data": { "events": { - "edges": [ - { - "cursor": "eyJ0eCI6NCwiZSI6MCwiYyI6MX0", - "node": { - "json": { - "new_value": "4" - } - } - }, - { - "cursor": "eyJ0eCI6NCwiZSI6MSwiYyI6MX0", - "node": { - "json": { - "new_value": "5" - } - } - } - ] + "edges": [] } } } diff --git a/crates/iota-graphql-e2e-tests/tests/event_connection/type_filter.exp b/crates/iota-graphql-e2e-tests/tests/event_connection/type_filter.exp index 94cafd894b3..fc1c99398df 100644 --- a/crates/iota-graphql-e2e-tests/tests/event_connection/type_filter.exp +++ b/crates/iota-graphql-e2e-tests/tests/event_connection/type_filter.exp @@ -30,7 +30,7 @@ Response: { "name": "M2" }, "type": { - "repr": "0xbd28426e10aae174ca0ee0574592a36e7b996541f639d2c042f8c1ec9a083c33::M1::EventA" + "repr": "0xd0c1754de67ee1c885b1c90d519183c869fa19832016a643da621a34262c8abe::M1::EventA" }, "sender": { "address": "0x8cca4e1ce0ba5904cea61df9242da2f7d29e3ef328fb7ec07c086b3bf47ca61a" @@ -72,7 +72,7 @@ Response: { "name": "M2" }, "type": { - "repr": "0xbd28426e10aae174ca0ee0574592a36e7b996541f639d2c042f8c1ec9a083c33::M1::EventA" + "repr": "0xd0c1754de67ee1c885b1c90d519183c869fa19832016a643da621a34262c8abe::M1::EventA" }, "sender": { "address": "0x8cca4e1ce0ba5904cea61df9242da2f7d29e3ef328fb7ec07c086b3bf47ca61a" @@ -98,7 +98,7 @@ Response: { "name": "M2" }, "type": { - "repr": "0xbd28426e10aae174ca0ee0574592a36e7b996541f639d2c042f8c1ec9a083c33::M2::EventB" + "repr": "0xd0c1754de67ee1c885b1c90d519183c869fa19832016a643da621a34262c8abe::M2::EventB" }, "sender": { "address": "0x8cca4e1ce0ba5904cea61df9242da2f7d29e3ef328fb7ec07c086b3bf47ca61a" @@ -124,7 +124,7 @@ Response: { "name": "M2" }, "type": { - "repr": "0xbd28426e10aae174ca0ee0574592a36e7b996541f639d2c042f8c1ec9a083c33::M1::EventA" + "repr": "0xd0c1754de67ee1c885b1c90d519183c869fa19832016a643da621a34262c8abe::M1::EventA" }, "sender": { "address": "0x8cca4e1ce0ba5904cea61df9242da2f7d29e3ef328fb7ec07c086b3bf47ca61a" @@ -139,7 +139,7 @@ Response: { "name": "M2" }, "type": { - "repr": "0xbd28426e10aae174ca0ee0574592a36e7b996541f639d2c042f8c1ec9a083c33::M2::EventB" + "repr": "0xd0c1754de67ee1c885b1c90d519183c869fa19832016a643da621a34262c8abe::M2::EventB" }, "sender": { "address": "0x8cca4e1ce0ba5904cea61df9242da2f7d29e3ef328fb7ec07c086b3bf47ca61a" @@ -165,7 +165,7 @@ Response: { "name": "M2" }, "type": { - "repr": "0xbd28426e10aae174ca0ee0574592a36e7b996541f639d2c042f8c1ec9a083c33::M1::EventA" + "repr": "0xd0c1754de67ee1c885b1c90d519183c869fa19832016a643da621a34262c8abe::M1::EventA" }, "sender": { "address": "0x8cca4e1ce0ba5904cea61df9242da2f7d29e3ef328fb7ec07c086b3bf47ca61a" @@ -180,7 +180,7 @@ Response: { "name": "M2" }, "type": { - "repr": "0xbd28426e10aae174ca0ee0574592a36e7b996541f639d2c042f8c1ec9a083c33::M2::EventB" + "repr": "0xd0c1754de67ee1c885b1c90d519183c869fa19832016a643da621a34262c8abe::M2::EventB" }, "sender": { "address": "0x8cca4e1ce0ba5904cea61df9242da2f7d29e3ef328fb7ec07c086b3bf47ca61a" @@ -195,7 +195,7 @@ Response: { "name": "M2" }, "type": { - "repr": "0xbd28426e10aae174ca0ee0574592a36e7b996541f639d2c042f8c1ec9a083c33::M2::EventB" + "repr": "0xd0c1754de67ee1c885b1c90d519183c869fa19832016a643da621a34262c8abe::M2::EventB" }, "sender": { "address": "0x28f02a953f3553f51a9365593c7d4bd0643d2085f004b18c6ca9de51682b2c80" diff --git a/crates/iota-graphql-e2e-tests/tests/event_connection/type_param_filter.exp b/crates/iota-graphql-e2e-tests/tests/event_connection/type_param_filter.exp index b76b284381b..38b26be0442 100644 --- a/crates/iota-graphql-e2e-tests/tests/event_connection/type_param_filter.exp +++ b/crates/iota-graphql-e2e-tests/tests/event_connection/type_param_filter.exp @@ -38,19 +38,19 @@ Response: { "transactionBlocks": { "nodes": [ { - "digest": "8twBu7kvzDbfSLjpBJ2GbDpfARJpwkdVCywZJqQCc3Eu" + "digest": "b5R95kKQ5woMzx3Qv8GjKKG7JZZLLsg1DAFkuKULx7V" }, { - "digest": "DajMe5yQb58g3mEg5Lro7654ttnUL7WYbAcfdJQusLQy" + "digest": "5g71h54kuLvR1x5RBRZFHeqUjyx7o7DhxFvHzu9BVbMA" }, { - "digest": "HBZfkNS4HTKTqSf6xsBBrBkTP9FTP8s2kFHYEeGV3i2F" + "digest": "HB6E8FBSJw7ViXKkqmZTAgY5t4E5uainW5BtWSbbWfTu" }, { - "digest": "FMUBpggCSevRg1mMsj7xyJ8Hcwk1u49SWnZo2arciPxM" + "digest": "4Aa1YhftZmqnzDfvMk2oTatJjvYY2PVtne7FchQXfgTU" }, { - "digest": "ECJhnduFaZDQdcnG6iNdKweAnq6LvgnkvuDWVkAFwywj" + "digest": "4LHstjfZQD885Hedg7trd3JZRLomEp1kg1XYrrG8J62L" } ] } @@ -65,7 +65,7 @@ Response: { "nodes": [ { "type": { - "repr": "0xf15189808de27b1c917c0f82626b69bf4a2fd46948f2e8e26f8af93634124cb2::M1::EventA<0xf15189808de27b1c917c0f82626b69bf4a2fd46948f2e8e26f8af93634124cb2::M1::T1>" + "repr": "0x7e8ea8dea7457d536129c24c102f5c30684fe36adf5c87a5bad5be2ff7d00ae5::M1::EventA<0x7e8ea8dea7457d536129c24c102f5c30684fe36adf5c87a5bad5be2ff7d00ae5::M1::T1>" }, "sender": { "address": "0x8cca4e1ce0ba5904cea61df9242da2f7d29e3ef328fb7ec07c086b3bf47ca61a" @@ -78,7 +78,7 @@ Response: { }, { "type": { - "repr": "0xf15189808de27b1c917c0f82626b69bf4a2fd46948f2e8e26f8af93634124cb2::M1::EventA<0xf15189808de27b1c917c0f82626b69bf4a2fd46948f2e8e26f8af93634124cb2::M1::T2>" + "repr": "0x7e8ea8dea7457d536129c24c102f5c30684fe36adf5c87a5bad5be2ff7d00ae5::M1::EventA<0x7e8ea8dea7457d536129c24c102f5c30684fe36adf5c87a5bad5be2ff7d00ae5::M1::T2>" }, "sender": { "address": "0x8cca4e1ce0ba5904cea61df9242da2f7d29e3ef328fb7ec07c086b3bf47ca61a" @@ -91,7 +91,7 @@ Response: { }, { "type": { - "repr": "0xf15189808de27b1c917c0f82626b69bf4a2fd46948f2e8e26f8af93634124cb2::M1::EventA<0xf15189808de27b1c917c0f82626b69bf4a2fd46948f2e8e26f8af93634124cb2::M1::T1>" + "repr": "0x7e8ea8dea7457d536129c24c102f5c30684fe36adf5c87a5bad5be2ff7d00ae5::M1::EventA<0x7e8ea8dea7457d536129c24c102f5c30684fe36adf5c87a5bad5be2ff7d00ae5::M1::T1>" }, "sender": { "address": "0x8cca4e1ce0ba5904cea61df9242da2f7d29e3ef328fb7ec07c086b3bf47ca61a" @@ -104,7 +104,7 @@ Response: { }, { "type": { - "repr": "0xf15189808de27b1c917c0f82626b69bf4a2fd46948f2e8e26f8af93634124cb2::M1::EventA<0xf15189808de27b1c917c0f82626b69bf4a2fd46948f2e8e26f8af93634124cb2::M1::T2>" + "repr": "0x7e8ea8dea7457d536129c24c102f5c30684fe36adf5c87a5bad5be2ff7d00ae5::M1::EventA<0x7e8ea8dea7457d536129c24c102f5c30684fe36adf5c87a5bad5be2ff7d00ae5::M1::T2>" }, "sender": { "address": "0x8cca4e1ce0ba5904cea61df9242da2f7d29e3ef328fb7ec07c086b3bf47ca61a" @@ -128,7 +128,7 @@ Response: { "nodes": [ { "type": { - "repr": "0xf15189808de27b1c917c0f82626b69bf4a2fd46948f2e8e26f8af93634124cb2::M1::EventA<0xf15189808de27b1c917c0f82626b69bf4a2fd46948f2e8e26f8af93634124cb2::M1::T1>" + "repr": "0x7e8ea8dea7457d536129c24c102f5c30684fe36adf5c87a5bad5be2ff7d00ae5::M1::EventA<0x7e8ea8dea7457d536129c24c102f5c30684fe36adf5c87a5bad5be2ff7d00ae5::M1::T1>" }, "sender": { "address": "0x8cca4e1ce0ba5904cea61df9242da2f7d29e3ef328fb7ec07c086b3bf47ca61a" @@ -141,7 +141,7 @@ Response: { }, { "type": { - "repr": "0xf15189808de27b1c917c0f82626b69bf4a2fd46948f2e8e26f8af93634124cb2::M1::EventA<0xf15189808de27b1c917c0f82626b69bf4a2fd46948f2e8e26f8af93634124cb2::M1::T1>" + "repr": "0x7e8ea8dea7457d536129c24c102f5c30684fe36adf5c87a5bad5be2ff7d00ae5::M1::EventA<0x7e8ea8dea7457d536129c24c102f5c30684fe36adf5c87a5bad5be2ff7d00ae5::M1::T1>" }, "sender": { "address": "0x8cca4e1ce0ba5904cea61df9242da2f7d29e3ef328fb7ec07c086b3bf47ca61a" @@ -162,21 +162,7 @@ task 9, lines 80-95: Response: { "data": { "events": { - "nodes": [ - { - "type": { - "repr": "0xf15189808de27b1c917c0f82626b69bf4a2fd46948f2e8e26f8af93634124cb2::M1::EventA<0xf15189808de27b1c917c0f82626b69bf4a2fd46948f2e8e26f8af93634124cb2::M1::T2>" - }, - "sender": { - "address": "0x8cca4e1ce0ba5904cea61df9242da2f7d29e3ef328fb7ec07c086b3bf47ca61a" - }, - "json": { - "value": { - "dummy_field": false - } - } - } - ] + "nodes": [] } } } diff --git a/crates/iota-graphql-e2e-tests/tests/limits/directives.exp b/crates/iota-graphql-e2e-tests/tests/limits/directives.exp index e01ddb91d62..3a26175bed6 100644 --- a/crates/iota-graphql-e2e-tests/tests/limits/directives.exp +++ b/crates/iota-graphql-e2e-tests/tests/limits/directives.exp @@ -73,7 +73,7 @@ task 5, lines 59-63: //# run-graphql Response: { "data": { - "chainIdentifier": "e1d5137d" + "chainIdentifier": "e50daeb7" } } @@ -81,7 +81,7 @@ task 6, lines 65-69: //# run-graphql Response: { "data": { - "chainIdentifier": "e1d5137d" + "chainIdentifier": "e50daeb7" } } diff --git a/crates/iota-graphql-e2e-tests/tests/limits/output_node_estimation.exp b/crates/iota-graphql-e2e-tests/tests/limits/output_node_estimation.exp index 16e0028a7a4..3df92edd511 100644 --- a/crates/iota-graphql-e2e-tests/tests/limits/output_node_estimation.exp +++ b/crates/iota-graphql-e2e-tests/tests/limits/output_node_estimation.exp @@ -30,7 +30,7 @@ Response: { "edges": [ { "node": { - "digest": "Cpgs1hPAQs2nfbQkD2ZsEfEAvmtTjb7QT5mtXaMQwhgD" + "digest": "3i3tgknuHtmwGpo2ybxbvVmBUsTWpaaWvKxbEKzc279Q" } } ] @@ -59,7 +59,7 @@ Response: { "edges": [ { "txns": { - "digest": "Cpgs1hPAQs2nfbQkD2ZsEfEAvmtTjb7QT5mtXaMQwhgD" + "digest": "3i3tgknuHtmwGpo2ybxbvVmBUsTWpaaWvKxbEKzc279Q" } } ] @@ -91,7 +91,7 @@ Response: { "edges": [ { "txns": { - "digest": "Cpgs1hPAQs2nfbQkD2ZsEfEAvmtTjb7QT5mtXaMQwhgD" + "digest": "3i3tgknuHtmwGpo2ybxbvVmBUsTWpaaWvKxbEKzc279Q" } } ] @@ -100,7 +100,7 @@ Response: { "edges": [ { "txns": { - "digest": "Cpgs1hPAQs2nfbQkD2ZsEfEAvmtTjb7QT5mtXaMQwhgD" + "digest": "3i3tgknuHtmwGpo2ybxbvVmBUsTWpaaWvKxbEKzc279Q" } } ] @@ -132,7 +132,7 @@ Response: { "edges": [ { "txns": { - "digest": "Cpgs1hPAQs2nfbQkD2ZsEfEAvmtTjb7QT5mtXaMQwhgD" + "digest": "3i3tgknuHtmwGpo2ybxbvVmBUsTWpaaWvKxbEKzc279Q" } } ] @@ -164,7 +164,7 @@ Response: { "edges": [ { "txns": { - "digest": "Cpgs1hPAQs2nfbQkD2ZsEfEAvmtTjb7QT5mtXaMQwhgD" + "digest": "3i3tgknuHtmwGpo2ybxbvVmBUsTWpaaWvKxbEKzc279Q" } } ] @@ -190,7 +190,7 @@ Response: { "edges": [ { "txns": { - "digest": "Cpgs1hPAQs2nfbQkD2ZsEfEAvmtTjb7QT5mtXaMQwhgD" + "digest": "3i3tgknuHtmwGpo2ybxbvVmBUsTWpaaWvKxbEKzc279Q" } } ] @@ -216,7 +216,7 @@ Response: { "edges": [ { "txns": { - "digest": "Cpgs1hPAQs2nfbQkD2ZsEfEAvmtTjb7QT5mtXaMQwhgD", + "digest": "3i3tgknuHtmwGpo2ybxbvVmBUsTWpaaWvKxbEKzc279Q", "first": null, "last": null } @@ -243,7 +243,7 @@ Response: { "transactionBlocks": { "nodes": [ { - "digest": "Cpgs1hPAQs2nfbQkD2ZsEfEAvmtTjb7QT5mtXaMQwhgD", + "digest": "3i3tgknuHtmwGpo2ybxbvVmBUsTWpaaWvKxbEKzc279Q", "first": null, "last": null } @@ -270,7 +270,7 @@ Response: { "edges": [ { "txns": { - "digest": "Cpgs1hPAQs2nfbQkD2ZsEfEAvmtTjb7QT5mtXaMQwhgD", + "digest": "3i3tgknuHtmwGpo2ybxbvVmBUsTWpaaWvKxbEKzc279Q", "a": null, "b": null } @@ -324,7 +324,7 @@ Response: { "edges": [ { "node": { - "digest": "Cpgs1hPAQs2nfbQkD2ZsEfEAvmtTjb7QT5mtXaMQwhgD", + "digest": "3i3tgknuHtmwGpo2ybxbvVmBUsTWpaaWvKxbEKzc279Q", "a": null } } @@ -350,14 +350,14 @@ Response: { "fragmentSpread": { "nodes": [ { - "digest": "Cpgs1hPAQs2nfbQkD2ZsEfEAvmtTjb7QT5mtXaMQwhgD" + "digest": "3i3tgknuHtmwGpo2ybxbvVmBUsTWpaaWvKxbEKzc279Q" } ] }, "inlineFragment": { "nodes": [ { - "digest": "Cpgs1hPAQs2nfbQkD2ZsEfEAvmtTjb7QT5mtXaMQwhgD" + "digest": "3i3tgknuHtmwGpo2ybxbvVmBUsTWpaaWvKxbEKzc279Q" } ] } diff --git a/crates/iota-graphql-e2e-tests/tests/objects/coin.exp b/crates/iota-graphql-e2e-tests/tests/objects/coin.exp index 9375b4e1bb2..4b469acf639 100644 --- a/crates/iota-graphql-e2e-tests/tests/objects/coin.exp +++ b/crates/iota-graphql-e2e-tests/tests/objects/coin.exp @@ -21,9 +21,9 @@ Response: { "iotaCoins": { "edges": [ { - "cursor": "IBao6IhDn7hl4uu2XYkOhyvmcXQU9AHwebV0HmdGfKQcAQAAAAAAAAA=", + "cursor": "IDejnNtJDt+1jyfOdjn/AmGFmbJKC5F0/KuBPLyO8udXAQAAAAAAAAA=", "node": { - "coinBalance": "299999983336400", + "coinBalance": "300000000000000", "contents": { "type": { "repr": "0x0000000000000000000000000000000000000000000000000000000000000002::coin::Coin<0x0000000000000000000000000000000000000000000000000000000000000002::iota::IOTA>" @@ -32,7 +32,7 @@ Response: { } }, { - "cursor": "IIz+6PGvwXCeVC7Vm0H9kJEMAsXnzlBZzrSz99JdySOdAQAAAAAAAAA=", + "cursor": "IDgbuPdj3DERVIhMGJwCcgQoCE4bFkx+/qB1PI67n6GpAQAAAAAAAAA=", "node": { "coinBalance": "30000000000000000", "contents": { @@ -43,9 +43,9 @@ Response: { } }, { - "cursor": "IJvawMH0VbgEh/ZtB0erXxE+/rzdAlj0WIt3JzjQs8sRAQAAAAAAAAA=", + "cursor": "IFwSkvmC5PQWLWvaf5IXfTXG0M+7W1MXqRJp0GD7eqevAQAAAAAAAAA=", "node": { - "coinBalance": "300000000000000", + "coinBalance": "299999983336400", "contents": { "type": { "repr": "0x0000000000000000000000000000000000000000000000000000000000000002::coin::Coin<0x0000000000000000000000000000000000000000000000000000000000000002::iota::IOTA>" @@ -58,34 +58,34 @@ Response: { "fakeCoins": { "edges": [ { - "cursor": "IIg4QyiMWUOTVMNTmRkL1HIQr7k/z9dcG4oAetb6QjbGAQAAAAAAAAA=", + "cursor": "IFCto+HqZV+CA8GBbQb2iMg8le5if61nfX42FTETumcCAQAAAAAAAAA=", "node": { "coinBalance": "2", "contents": { "type": { - "repr": "0x0000000000000000000000000000000000000000000000000000000000000002::coin::Coin<0x5427c77851d42bea4fbbfe56724d57756b843e2038f23785cef5b9559d01bef8::fake::FAKE>" + "repr": "0x0000000000000000000000000000000000000000000000000000000000000002::coin::Coin<0x2caad413fb46e9995cb54309ae71b27542e9b488bee334ef06b4c7b55f428244::fake::FAKE>" } } } }, { - "cursor": "IImP7Bx+qUUTyvUk5wSrKU90abCFrbzb0AfgLca4fyV7AQAAAAAAAAA=", + "cursor": "IFV0yl/uDtBt31BwG5TvuT3wC39K/QLYZR8CY2zz6fWiAQAAAAAAAAA=", "node": { - "coinBalance": "1", + "coinBalance": "3", "contents": { "type": { - "repr": "0x0000000000000000000000000000000000000000000000000000000000000002::coin::Coin<0x5427c77851d42bea4fbbfe56724d57756b843e2038f23785cef5b9559d01bef8::fake::FAKE>" + "repr": "0x0000000000000000000000000000000000000000000000000000000000000002::coin::Coin<0x2caad413fb46e9995cb54309ae71b27542e9b488bee334ef06b4c7b55f428244::fake::FAKE>" } } } }, { - "cursor": "IJU3paGJOHPouEf9+iN6nqiqFacvNzEI//kR9mj6PQYiAQAAAAAAAAA=", + "cursor": "IGoY5Cxim76LrxXqiV10mZkP90+uEwSgkekjLUCbpHwbAQAAAAAAAAA=", "node": { - "coinBalance": "3", + "coinBalance": "1", "contents": { "type": { - "repr": "0x0000000000000000000000000000000000000000000000000000000000000002::coin::Coin<0x5427c77851d42bea4fbbfe56724d57756b843e2038f23785cef5b9559d01bef8::fake::FAKE>" + "repr": "0x0000000000000000000000000000000000000000000000000000000000000002::coin::Coin<0x2caad413fb46e9995cb54309ae71b27542e9b488bee334ef06b4c7b55f428244::fake::FAKE>" } } } @@ -96,7 +96,7 @@ Response: { "coins": { "edges": [ { - "cursor": "IBao6IhDn7hl4uu2XYkOhyvmcXQU9AHwebV0HmdGfKQcAQAAAAAAAAA=", + "cursor": "IFwSkvmC5PQWLWvaf5IXfTXG0M+7W1MXqRJp0GD7eqevAQAAAAAAAAA=", "node": { "coinBalance": "299999983336400", "contents": { @@ -121,10 +121,10 @@ Response: { } }, { - "cursor": "eyJ0IjoiMHg1NDI3Yzc3ODUxZDQyYmVhNGZiYmZlNTY3MjRkNTc3NTZiODQzZTIwMzhmMjM3ODVjZWY1Yjk1NTlkMDFiZWY4OjpmYWtlOjpGQUtFIiwiYyI6MX0", + "cursor": "eyJ0IjoiMHgyY2FhZDQxM2ZiNDZlOTk5NWNiNTQzMDlhZTcxYjI3NTQyZTliNDg4YmVlMzM0ZWYwNmI0YzdiNTVmNDI4MjQ0OjpmYWtlOjpGQUtFIiwiYyI6MX0", "node": { "coinType": { - "repr": "0x5427c77851d42bea4fbbfe56724d57756b843e2038f23785cef5b9559d01bef8::fake::FAKE" + "repr": "0x2caad413fb46e9995cb54309ae71b27542e9b488bee334ef06b4c7b55f428244::fake::FAKE" }, "coinObjectCount": 3, "totalBalance": "6" @@ -142,7 +142,7 @@ Response: { "lastBalance": { "edges": [ { - "cursor": "eyJ0IjoiMHg1NDI3Yzc3ODUxZDQyYmVhNGZiYmZlNTY3MjRkNTc3NTZiODQzZTIwMzhmMjM3ODVjZWY1Yjk1NTlkMDFiZWY4OjpmYWtlOjpGQUtFIiwiYyI6MX0" + "cursor": "eyJ0IjoiMHgyY2FhZDQxM2ZiNDZlOTk5NWNiNTQzMDlhZTcxYjI3NTQyZTliNDg4YmVlMzM0ZWYwNmI0YzdiNTVmNDI4MjQ0OjpmYWtlOjpGQUtFIiwiYyI6MX0" } ] } diff --git a/crates/iota-graphql-e2e-tests/tests/objects/data.exp b/crates/iota-graphql-e2e-tests/tests/objects/data.exp index e9559c6c1ae..1f0d46d93da 100644 --- a/crates/iota-graphql-e2e-tests/tests/objects/data.exp +++ b/crates/iota-graphql-e2e-tests/tests/objects/data.exp @@ -44,38 +44,38 @@ Response: { "name": "id", "value": { "UID": [ - 155, - 218, - 192, - 193, - 244, - 85, - 184, - 4, - 135, - 246, - 109, - 7, - 71, + 55, + 163, + 156, + 219, + 73, + 14, + 223, + 181, + 143, + 39, + 206, + 118, + 57, + 255, + 2, + 97, + 133, + 153, + 178, + 74, + 11, + 145, + 116, + 252, 171, - 95, - 17, - 62, - 254, + 129, + 60, 188, - 221, - 2, - 88, - 244, - 88, - 139, - 119, - 39, - 56, - 208, - 179, - 203, - 17 + 142, + 242, + 231, + 87 ] } }, @@ -95,7 +95,7 @@ Response: { ] }, "json": { - "id": "0x9bdac0c1f455b80487f66d0747ab5f113efebcdd0258f4588b772738d0b3cb11", + "id": "0x37a39cdb490edfb58f27ce7639ff02618599b24a0b9174fcab813cbc8ef2e757", "balance": { "value": "299999988454400" } @@ -109,7 +109,7 @@ Response: { "asMoveObject": { "contents": { "type": { - "repr": "0xaac88efdf69f44a44633c28935fc8834a333cdd1372ae3f9b858eb897bb52c14::m::Foo" + "repr": "0xc215a5eb339690806ff0ed48ab6a08e3378593c49d809b4cbdaaadab8ce089e2::m::Foo" }, "data": { "Struct": [ @@ -117,38 +117,38 @@ Response: { "name": "id", "value": { "UID": [ - 222, - 16, - 127, - 78, - 164, + 170, + 104, + 165, + 190, 189, - 180, - 48, - 5, - 65, - 191, - 115, - 225, - 187, - 228, - 4, - 78, - 29, - 216, - 201, 12, - 74, - 221, - 186, - 81, - 50, - 245, - 14, - 57, - 227, - 96, - 40 + 236, + 125, + 250, + 29, + 35, + 7, + 134, + 66, + 125, + 140, + 205, + 66, + 59, + 114, + 206, + 204, + 177, + 155, + 246, + 42, + 111, + 233, + 169, + 83, + 26, + 154 ] } }, @@ -156,38 +156,38 @@ Response: { "name": "f0", "value": { "ID": [ - 222, - 16, - 127, - 78, - 164, + 170, + 104, + 165, + 190, 189, - 180, - 48, - 5, - 65, - 191, - 115, - 225, - 187, - 228, - 4, - 78, - 29, - 216, - 201, 12, - 74, - 221, - 186, - 81, - 50, - 245, - 14, - 57, - 227, - 96, - 40 + 236, + 125, + 250, + 29, + 35, + 7, + 134, + 66, + 125, + 140, + 205, + 66, + 59, + 114, + 206, + 204, + 177, + 155, + 246, + 42, + 111, + 233, + 169, + 83, + 26, + 154 ] } }, @@ -227,38 +227,38 @@ Response: { "Vector": [ { "Address": [ - 222, - 16, - 127, - 78, - 164, + 170, + 104, + 165, + 190, 189, - 180, - 48, - 5, - 65, - 191, - 115, - 225, - 187, - 228, - 4, - 78, - 29, - 216, - 201, 12, - 74, - 221, - 186, - 81, - 50, - 245, - 14, - 57, - 227, - 96, - 40 + 236, + 125, + 250, + 29, + 35, + 7, + 134, + 66, + 125, + 140, + 205, + 66, + 59, + 114, + 206, + 204, + 177, + 155, + 246, + 42, + 111, + 233, + 169, + 83, + 26, + 154 ] } ] @@ -275,15 +275,15 @@ Response: { ] }, "json": { - "id": "0xde107f4ea4bdb4300541bf73e1bbe4044e1dd8c90c4addba5132f50e39e36028", - "f0": "0xde107f4ea4bdb4300541bf73e1bbe4044e1dd8c90c4addba5132f50e39e36028", + "id": "0xaa68a5bebd0cec7dfa1d230786427d8ccd423b72ceccb19bf62a6fe9a9531a9a", + "f0": "0xaa68a5bebd0cec7dfa1d230786427d8ccd423b72ceccb19bf62a6fe9a9531a9a", "f1": true, "f2": 42, "f3": "43", "f4": "hello", "f5": "world", "f6": [ - "0xde107f4ea4bdb4300541bf73e1bbe4044e1dd8c90c4addba5132f50e39e36028" + "0xaa68a5bebd0cec7dfa1d230786427d8ccd423b72ceccb19bf62a6fe9a9531a9a" ], "f7": 44 } diff --git a/crates/iota-graphql-e2e-tests/tests/objects/display.exp b/crates/iota-graphql-e2e-tests/tests/objects/display.exp index 55af5c6afcf..7941b8b3129 100644 --- a/crates/iota-graphql-e2e-tests/tests/objects/display.exp +++ b/crates/iota-graphql-e2e-tests/tests/objects/display.exp @@ -5,7 +5,7 @@ A: object(0,0) task 1, lines 7-131: //# publish --sender A -events: Event { package_id: Test, transaction_module: Identifier("boars"), sender: A, type_: StructTag { address: iota, module: Identifier("display"), name: Identifier("DisplayCreated"), type_params: [Struct(StructTag { address: Test, module: Identifier("boars"), name: Identifier("Boar"), type_params: [] })] }, contents: [91, 12, 10, 43, 119, 160, 47, 175, 213, 37, 57, 38, 91, 66, 168, 83, 130, 247, 170, 150, 13, 25, 185, 175, 7, 21, 197, 128, 93, 72, 108, 33] } +events: Event { package_id: Test, transaction_module: Identifier("boars"), sender: A, type_: StructTag { address: iota, module: Identifier("display"), name: Identifier("DisplayCreated"), type_params: [Struct(StructTag { address: Test, module: Identifier("boars"), name: Identifier("Boar"), type_params: [] })] }, contents: [200, 150, 132, 71, 202, 137, 3, 87, 222, 224, 67, 232, 54, 156, 171, 125, 11, 72, 193, 0, 129, 141, 189, 40, 19, 179, 119, 175, 62, 234, 214, 245] } created: object(1,0), object(1,1), object(1,2) mutated: object(0,0) gas summary: computation_cost: 1000000, storage_cost: 21470000, storage_rebate: 0, non_refundable_storage_fee: 0 @@ -16,7 +16,7 @@ Checkpoint created: 1 task 3, line 135: //# view-checkpoint -CheckpointSummary { epoch: 0, seq: 1, content_digest: DbUNZNH3kBMZDctWEPfNqahnKKDU2AQAm2JuXameKnri, +CheckpointSummary { epoch: 0, seq: 1, content_digest: DxfuAPNDXR3iEjnafeAcqMdMmZaUKvkpomSmuuWYyE4o, epoch_rolling_gas_cost_summary: GasCostSummary { computation_cost: 1000000, storage_cost: 21470000, storage_rebate: 0, non_refundable_storage_fee: 0 }} task 4, line 137: @@ -27,7 +27,7 @@ gas summary: computation_cost: 1000000, storage_cost: 3556800, storage_rebate: task 5, line 139: //# run Test::boars::update_display_faulty --sender A --args object(1,1) -events: Event { package_id: Test, transaction_module: Identifier("boars"), sender: A, type_: StructTag { address: iota, module: Identifier("display"), name: Identifier("VersionUpdated"), type_params: [Struct(StructTag { address: Test, module: Identifier("boars"), name: Identifier("Boar"), type_params: [] })] }, contents: [91, 12, 10, 43, 119, 160, 47, 175, 213, 37, 57, 38, 91, 66, 168, 83, 130, 247, 170, 150, 13, 25, 185, 175, 7, 21, 197, 128, 93, 72, 108, 33, 1, 0, 3, 7, 118, 101, 99, 116, 111, 114, 115, 5, 123, 118, 101, 99, 125, 3, 105, 100, 100, 5, 123, 105, 100, 100, 125, 5, 110, 97, 109, 101, 101, 7, 123, 110, 97, 109, 101, 101, 125] } +events: Event { package_id: Test, transaction_module: Identifier("boars"), sender: A, type_: StructTag { address: iota, module: Identifier("display"), name: Identifier("VersionUpdated"), type_params: [Struct(StructTag { address: Test, module: Identifier("boars"), name: Identifier("Boar"), type_params: [] })] }, contents: [200, 150, 132, 71, 202, 137, 3, 87, 222, 224, 67, 232, 54, 156, 171, 125, 11, 72, 193, 0, 129, 141, 189, 40, 19, 179, 119, 175, 62, 234, 214, 245, 1, 0, 3, 7, 118, 101, 99, 116, 111, 114, 115, 5, 123, 118, 101, 99, 125, 3, 105, 100, 100, 5, 123, 105, 100, 100, 125, 5, 110, 97, 109, 101, 101, 7, 123, 110, 97, 109, 101, 101, 125] } mutated: object(0,0), object(1,1) gas summary: computation_cost: 1000000, storage_cost: 2941200, storage_rebate: 2652400, non_refundable_storage_fee: 0 @@ -37,7 +37,7 @@ Checkpoint created: 2 task 7, line 143: //# view-checkpoint -CheckpointSummary { epoch: 0, seq: 2, content_digest: AXoLpv4nzVNNQWqZZDvvErHqqZ7inju4FDZHfXxs2WH3, +CheckpointSummary { epoch: 0, seq: 2, content_digest: 2Q2Sh3RdhFkt4XKHPSMoX4ZUfVyY7eFdJuAi6HJHgcUf, epoch_rolling_gas_cost_summary: GasCostSummary { computation_cost: 3000000, storage_cost: 27968000, storage_rebate: 3640400, non_refundable_storage_fee: 0 }} task 8, lines 145-158: @@ -74,7 +74,7 @@ Response: { task 9, line 160: //# run Test::boars::single_add --sender A --args object(1,1) -events: Event { package_id: Test, transaction_module: Identifier("boars"), sender: A, type_: StructTag { address: iota, module: Identifier("display"), name: Identifier("VersionUpdated"), type_params: [Struct(StructTag { address: Test, module: Identifier("boars"), name: Identifier("Boar"), type_params: [] })] }, contents: [91, 12, 10, 43, 119, 160, 47, 175, 213, 37, 57, 38, 91, 66, 168, 83, 130, 247, 170, 150, 13, 25, 185, 175, 7, 21, 197, 128, 93, 72, 108, 33, 2, 0, 4, 7, 118, 101, 99, 116, 111, 114, 115, 5, 123, 118, 101, 99, 125, 3, 105, 100, 100, 5, 123, 105, 100, 100, 125, 5, 110, 97, 109, 101, 101, 7, 123, 110, 97, 109, 101, 101, 125, 4, 110, 117, 109, 115, 6, 123, 110, 117, 109, 115, 125] } +events: Event { package_id: Test, transaction_module: Identifier("boars"), sender: A, type_: StructTag { address: iota, module: Identifier("display"), name: Identifier("VersionUpdated"), type_params: [Struct(StructTag { address: Test, module: Identifier("boars"), name: Identifier("Boar"), type_params: [] })] }, contents: [200, 150, 132, 71, 202, 137, 3, 87, 222, 224, 67, 232, 54, 156, 171, 125, 11, 72, 193, 0, 129, 141, 189, 40, 19, 179, 119, 175, 62, 234, 214, 245, 2, 0, 4, 7, 118, 101, 99, 116, 111, 114, 115, 5, 123, 118, 101, 99, 125, 3, 105, 100, 100, 5, 123, 105, 100, 100, 125, 5, 110, 97, 109, 101, 101, 7, 123, 110, 97, 109, 101, 101, 125, 4, 110, 117, 109, 115, 6, 123, 110, 117, 109, 115, 125] } mutated: object(0,0), object(1,1) gas summary: computation_cost: 1000000, storage_cost: 3032400, storage_rebate: 2941200, non_refundable_storage_fee: 0 @@ -84,7 +84,7 @@ Checkpoint created: 3 task 11, line 164: //# view-checkpoint -CheckpointSummary { epoch: 0, seq: 3, content_digest: 2BVqD56hZGPtPBg9bBdVJ9mrZNd2DStiCLKncnedfDEH, +CheckpointSummary { epoch: 0, seq: 3, content_digest: ApFyo1y4BfPaE3yHs2oSoCTgzUxmyAuzENCud6jPRvm6, epoch_rolling_gas_cost_summary: GasCostSummary { computation_cost: 4000000, storage_cost: 31000400, storage_rebate: 6581600, non_refundable_storage_fee: 0 }} task 12, lines 166-179: @@ -126,7 +126,7 @@ Response: { task 13, line 181: //# run Test::boars::multi_add --sender A --args object(1,1) -events: Event { package_id: Test, transaction_module: Identifier("boars"), sender: A, type_: StructTag { address: iota, module: Identifier("display"), name: Identifier("VersionUpdated"), type_params: [Struct(StructTag { address: Test, module: Identifier("boars"), name: Identifier("Boar"), type_params: [] })] }, contents: [91, 12, 10, 43, 119, 160, 47, 175, 213, 37, 57, 38, 91, 66, 168, 83, 130, 247, 170, 150, 13, 25, 185, 175, 7, 21, 197, 128, 93, 72, 108, 33, 3, 0, 15, 7, 118, 101, 99, 116, 111, 114, 115, 5, 123, 118, 101, 99, 125, 3, 105, 100, 100, 5, 123, 105, 100, 100, 125, 5, 110, 97, 109, 101, 101, 7, 123, 110, 97, 109, 101, 101, 125, 4, 110, 117, 109, 115, 6, 123, 110, 117, 109, 115, 125, 5, 98, 111, 111, 108, 115, 7, 123, 98, 111, 111, 108, 115, 125, 5, 98, 117, 121, 101, 114, 7, 123, 98, 117, 121, 101, 114, 125, 4, 110, 97, 109, 101, 6, 123, 110, 97, 109, 101, 125, 7, 99, 114, 101, 97, 116, 111, 114, 9, 123, 99, 114, 101, 97, 116, 111, 114, 125, 5, 112, 114, 105, 99, 101, 7, 123, 112, 114, 105, 99, 101, 125, 11, 112, 114, 111, 106, 101, 99, 116, 95, 117, 114, 108, 58, 85, 110, 105, 113, 117, 101, 32, 66, 111, 97, 114, 32, 102, 114, 111, 109, 32, 116, 104, 101, 32, 66, 111, 97, 114, 115, 32, 99, 111, 108, 108, 101, 99, 116, 105, 111, 110, 32, 119, 105, 116, 104, 32, 123, 110, 97, 109, 101, 125, 32, 97, 110, 100, 32, 123, 105, 100, 125, 8, 98, 97, 115, 101, 95, 117, 114, 108, 32, 104, 116, 116, 112, 115, 58, 47, 47, 103, 101, 116, 45, 97, 45, 98, 111, 97, 114, 46, 99, 111, 109, 47, 123, 105, 109, 103, 95, 117, 114, 108, 125, 11, 110, 111, 95, 116, 101, 109, 112, 108, 97, 116, 101, 23, 104, 116, 116, 112, 115, 58, 47, 47, 103, 101, 116, 45, 97, 45, 98, 111, 97, 114, 46, 99, 111, 109, 47, 3, 97, 103, 101, 21, 123, 109, 101, 116, 97, 100, 97, 116, 97, 46, 110, 101, 115, 116, 101, 100, 46, 97, 103, 101, 125, 8, 102, 117, 108, 108, 95, 117, 114, 108, 10, 123, 102, 117, 108, 108, 95, 117, 114, 108, 125, 13, 101, 115, 99, 97, 112, 101, 95, 115, 121, 110, 116, 97, 120, 8, 92, 123, 110, 97, 109, 101, 92, 125] } +events: Event { package_id: Test, transaction_module: Identifier("boars"), sender: A, type_: StructTag { address: iota, module: Identifier("display"), name: Identifier("VersionUpdated"), type_params: [Struct(StructTag { address: Test, module: Identifier("boars"), name: Identifier("Boar"), type_params: [] })] }, contents: [200, 150, 132, 71, 202, 137, 3, 87, 222, 224, 67, 232, 54, 156, 171, 125, 11, 72, 193, 0, 129, 141, 189, 40, 19, 179, 119, 175, 62, 234, 214, 245, 3, 0, 15, 7, 118, 101, 99, 116, 111, 114, 115, 5, 123, 118, 101, 99, 125, 3, 105, 100, 100, 5, 123, 105, 100, 100, 125, 5, 110, 97, 109, 101, 101, 7, 123, 110, 97, 109, 101, 101, 125, 4, 110, 117, 109, 115, 6, 123, 110, 117, 109, 115, 125, 5, 98, 111, 111, 108, 115, 7, 123, 98, 111, 111, 108, 115, 125, 5, 98, 117, 121, 101, 114, 7, 123, 98, 117, 121, 101, 114, 125, 4, 110, 97, 109, 101, 6, 123, 110, 97, 109, 101, 125, 7, 99, 114, 101, 97, 116, 111, 114, 9, 123, 99, 114, 101, 97, 116, 111, 114, 125, 5, 112, 114, 105, 99, 101, 7, 123, 112, 114, 105, 99, 101, 125, 11, 112, 114, 111, 106, 101, 99, 116, 95, 117, 114, 108, 58, 85, 110, 105, 113, 117, 101, 32, 66, 111, 97, 114, 32, 102, 114, 111, 109, 32, 116, 104, 101, 32, 66, 111, 97, 114, 115, 32, 99, 111, 108, 108, 101, 99, 116, 105, 111, 110, 32, 119, 105, 116, 104, 32, 123, 110, 97, 109, 101, 125, 32, 97, 110, 100, 32, 123, 105, 100, 125, 8, 98, 97, 115, 101, 95, 117, 114, 108, 32, 104, 116, 116, 112, 115, 58, 47, 47, 103, 101, 116, 45, 97, 45, 98, 111, 97, 114, 46, 99, 111, 109, 47, 123, 105, 109, 103, 95, 117, 114, 108, 125, 11, 110, 111, 95, 116, 101, 109, 112, 108, 97, 116, 101, 23, 104, 116, 116, 112, 115, 58, 47, 47, 103, 101, 116, 45, 97, 45, 98, 111, 97, 114, 46, 99, 111, 109, 47, 3, 97, 103, 101, 21, 123, 109, 101, 116, 97, 100, 97, 116, 97, 46, 110, 101, 115, 116, 101, 100, 46, 97, 103, 101, 125, 8, 102, 117, 108, 108, 95, 117, 114, 108, 10, 123, 102, 117, 108, 108, 95, 117, 114, 108, 125, 13, 101, 115, 99, 97, 112, 101, 95, 115, 121, 110, 116, 97, 120, 8, 92, 123, 110, 97, 109, 101, 92, 125] } mutated: object(0,0), object(1,1) gas summary: computation_cost: 1000000, storage_cost: 5236400, storage_rebate: 3032400, non_refundable_storage_fee: 0 @@ -136,7 +136,7 @@ Checkpoint created: 4 task 15, line 185: //# view-checkpoint -CheckpointSummary { epoch: 0, seq: 4, content_digest: EmMrLtLuyYesFUFnrqSgjozhxxtc4i5cyW1GE24TpqY5, +CheckpointSummary { epoch: 0, seq: 4, content_digest: 6fCKEnhwLRw8bcXBko1NumBU4z5ngG7Xtx5LXMTe8yY5, epoch_rolling_gas_cost_summary: GasCostSummary { computation_cost: 5000000, storage_cost: 36236800, storage_rebate: 9614000, non_refundable_storage_fee: 0 }} task 16, lines 187-200: @@ -195,7 +195,7 @@ Response: { }, { "key": "project_url", - "value": "Unique Boar from the Boars collection with First Boar and 0x1d14b05a0e4de04a366be5fb238a260b319e94a986a953f31ab9e0284fb0ca61", + "value": "Unique Boar from the Boars collection with First Boar and 0x9fdaf1c274354cbe0b3a6e0a13aa73c31941f73a54fbe72e84a077ddac456063", "error": null }, { diff --git a/crates/iota-graphql-e2e-tests/tests/objects/enum_data.exp b/crates/iota-graphql-e2e-tests/tests/objects/enum_data.exp index 6138279f370..e6a8ee29748 100644 --- a/crates/iota-graphql-e2e-tests/tests/objects/enum_data.exp +++ b/crates/iota-graphql-e2e-tests/tests/objects/enum_data.exp @@ -44,38 +44,38 @@ Response: { "name": "id", "value": { "UID": [ - 155, - 218, - 192, - 193, - 244, - 85, - 184, - 4, - 135, - 246, - 109, - 7, - 71, + 55, + 163, + 156, + 219, + 73, + 14, + 223, + 181, + 143, + 39, + 206, + 118, + 57, + 255, + 2, + 97, + 133, + 153, + 178, + 74, + 11, + 145, + 116, + 252, 171, - 95, - 17, - 62, - 254, + 129, + 60, 188, - 221, - 2, - 88, - 244, - 88, - 139, - 119, - 39, - 56, - 208, - 179, - 203, - 17 + 142, + 242, + 231, + 87 ] } }, @@ -95,7 +95,7 @@ Response: { ] }, "json": { - "id": "0x9bdac0c1f455b80487f66d0747ab5f113efebcdd0258f4588b772738d0b3cb11", + "id": "0x37a39cdb490edfb58f27ce7639ff02618599b24a0b9174fcab813cbc8ef2e757", "balance": { "value": "299999995967600" } @@ -109,7 +109,7 @@ Response: { "asMoveObject": { "contents": { "type": { - "repr": "0x66ec5f38cce33a6aeba11afe550856c87f6b57c585b69e14f0311447d5820c73::m::Foo" + "repr": "0xc169e760953e68805694f335ddbbfed580aa64864113acd7c81f9f4e34975ab6::m::Foo" }, "data": { "Struct": [ @@ -117,38 +117,38 @@ Response: { "name": "id", "value": { "UID": [ + 126, + 19, + 31, + 228, + 156, + 97, + 224, + 21, + 90, + 63, 185, - 241, - 144, - 30, - 249, - 175, - 178, + 127, + 37, 209, - 182, - 91, - 235, - 220, - 70, - 222, + 203, + 64, + 51, + 51, + 124, + 104, + 128, + 92, 101, - 82, - 67, 126, - 38, - 215, - 113, - 183, - 75, - 12, - 89, - 242, - 129, - 117, - 237, - 39, - 184, - 165 + 85, + 214, + 252, + 96, + 203, + 24, + 107, + 104 ] } }, @@ -156,38 +156,38 @@ Response: { "name": "f0", "value": { "ID": [ + 126, + 19, + 31, + 228, + 156, + 97, + 224, + 21, + 90, + 63, 185, - 241, - 144, - 30, - 249, - 175, - 178, + 127, + 37, 209, - 182, - 91, - 235, - 220, - 70, - 222, + 203, + 64, + 51, + 51, + 124, + 104, + 128, + 92, 101, - 82, - 67, 126, - 38, - 215, - 113, - 183, - 75, - 12, - 89, - 242, - 129, - 117, - 237, - 39, - 184, - 165 + 85, + 214, + 252, + 96, + 203, + 24, + 107, + 104 ] } }, @@ -227,38 +227,38 @@ Response: { "Vector": [ { "Address": [ + 126, + 19, + 31, + 228, + 156, + 97, + 224, + 21, + 90, + 63, 185, - 241, - 144, - 30, - 249, - 175, - 178, + 127, + 37, 209, - 182, - 91, - 235, - 220, - 70, - 222, + 203, + 64, + 51, + 51, + 124, + 104, + 128, + 92, 101, - 82, - 67, 126, - 38, - 215, - 113, - 183, - 75, - 12, - 89, - 242, - 129, - 117, - 237, - 39, - 184, - 165 + 85, + 214, + 252, + 96, + 203, + 24, + 107, + 104 ] } ] @@ -325,15 +325,15 @@ Response: { ] }, "json": { - "id": "0xb9f1901ef9afb2d1b65bebdc46de6552437e26d771b74b0c59f28175ed27b8a5", - "f0": "0xb9f1901ef9afb2d1b65bebdc46de6552437e26d771b74b0c59f28175ed27b8a5", + "id": "0x7e131fe49c61e0155a3fb97f25d1cb4033337c68805c657e55d6fc60cb186b68", + "f0": "0x7e131fe49c61e0155a3fb97f25d1cb4033337c68805c657e55d6fc60cb186b68", "f1": true, "f2": 42, "f3": "43", "f4": "hello", "f5": "world", "f6": [ - "0xb9f1901ef9afb2d1b65bebdc46de6552437e26d771b74b0c59f28175ed27b8a5" + "0x7e131fe49c61e0155a3fb97f25d1cb4033337c68805c657e55d6fc60cb186b68" ], "f7": 44, "f8": { diff --git a/crates/iota-graphql-e2e-tests/tests/objects/filter_by_type.exp b/crates/iota-graphql-e2e-tests/tests/objects/filter_by_type.exp index bd9162c4cb7..f77876181b8 100644 --- a/crates/iota-graphql-e2e-tests/tests/objects/filter_by_type.exp +++ b/crates/iota-graphql-e2e-tests/tests/objects/filter_by_type.exp @@ -21,11 +21,11 @@ gas summary: computation_cost: 1000000, storage_cost: 1976000, storage_rebate: task 4, lines 16-18: //# run 0x3::iota_system::request_add_stake --args object(0x5) object(3,0) @validator_0 --sender C -events: Event { package_id: iota_system, transaction_module: Identifier("iota_system"), sender: C, type_: StructTag { address: iota_system, module: Identifier("validator"), name: Identifier("StakingRequestEvent"), type_params: [] }, contents: [171, 56, 174, 116, 116, 231, 90, 122, 148, 80, 189, 213, 3, 8, 47, 190, 80, 171, 87, 32, 84, 9, 231, 203, 82, 3, 186, 181, 58, 235, 194, 1, 175, 163, 158, 79, 0, 218, 226, 120, 249, 119, 199, 198, 147, 10, 94, 44, 118, 232, 93, 23, 165, 38, 215, 36, 187, 206, 15, 184, 31, 176, 125, 76, 140, 202, 78, 28, 224, 186, 89, 4, 206, 166, 29, 249, 36, 45, 162, 247, 210, 158, 62, 243, 40, 251, 126, 192, 124, 8, 107, 59, 244, 124, 166, 26, 1, 0, 0, 0, 0, 0, 0, 0, 0, 228, 11, 84, 2, 0, 0, 0] } +events: Event { package_id: iota_system, transaction_module: Identifier("iota_system"), sender: C, type_: StructTag { address: iota_system, module: Identifier("validator"), name: Identifier("StakingRequestEvent"), type_params: [] }, contents: [135, 213, 224, 32, 91, 207, 0, 187, 34, 183, 14, 41, 167, 78, 77, 75, 138, 89, 173, 167, 170, 11, 38, 100, 45, 178, 245, 162, 113, 72, 177, 240, 175, 163, 158, 79, 0, 218, 226, 120, 249, 119, 199, 198, 147, 10, 94, 44, 118, 232, 93, 23, 165, 38, 215, 36, 187, 206, 15, 184, 31, 176, 125, 76, 140, 202, 78, 28, 224, 186, 89, 4, 206, 166, 29, 249, 36, 45, 162, 247, 210, 158, 62, 243, 40, 251, 126, 192, 124, 8, 107, 59, 244, 124, 166, 26, 1, 0, 0, 0, 0, 0, 0, 0, 0, 228, 11, 84, 2, 0, 0, 0] } created: object(4,0) mutated: object(_), 0x0000000000000000000000000000000000000000000000000000000000000005, object(0,0) deleted: object(3,0) -gas summary: computation_cost: 1000000, storage_cost: 14561600, storage_rebate: 1976000, non_refundable_storage_fee: 0 +gas summary: computation_cost: 1000000, storage_cost: 14523600, storage_rebate: 1976000, non_refundable_storage_fee: 0 task 5, line 19: //# create-checkpoint @@ -134,7 +134,7 @@ Response: { "asMoveObject": { "contents": { "type": { - "repr": "0x0000000000000000000000000000000000000000000000000000000000000002::coin::Coin<0x0000000000000000000000000000000000000000000000000000000000000002::iota::IOTA>" + "repr": "0x0000000000000000000000000000000000000000000000000000000000000002::dynamic_field::Field" } } } @@ -145,7 +145,7 @@ Response: { "asMoveObject": { "contents": { "type": { - "repr": "0x0000000000000000000000000000000000000000000000000000000000000002::display::Display<0x000000000000000000000000000000000000000000000000000000000000107a::nft::Nft>" + "repr": "0x0000000000000000000000000000000000000000000000000000000000000002::dynamic_field::Field" } } } @@ -156,7 +156,7 @@ Response: { "asMoveObject": { "contents": { "type": { - "repr": "0x0000000000000000000000000000000000000000000000000000000000000002::dynamic_field::Field,0x0000000000000000000000000000000000000000000000000000000000000002::timelock::SystemTimelockCap>" + "repr": "0x0000000000000000000000000000000000000000000000000000000000000002::coin::Coin<0x0000000000000000000000000000000000000000000000000000000000000002::iota::IOTA>" } } } @@ -167,7 +167,7 @@ Response: { "asMoveObject": { "contents": { "type": { - "repr": "0x0000000000000000000000000000000000000000000000000000000000000002::dynamic_field::Field" + "repr": "0x0000000000000000000000000000000000000000000000000000000000000002::coin::Coin<0x0000000000000000000000000000000000000000000000000000000000000002::iota::IOTA>" } } } @@ -178,7 +178,7 @@ Response: { "asMoveObject": { "contents": { "type": { - "repr": "0x0000000000000000000000000000000000000000000000000000000000000002::dynamic_field::Field" + "repr": "0x0000000000000000000000000000000000000000000000000000000000000002::dynamic_field::Field,0x0000000000000000000000000000000000000000000000000000000000000002::timelock::SystemTimelockCap>" } } } @@ -189,7 +189,7 @@ Response: { "asMoveObject": { "contents": { "type": { - "repr": "0x0000000000000000000000000000000000000000000000000000000000000002::coin::CoinMetadata<0x0000000000000000000000000000000000000000000000000000000000000002::iota::IOTA>" + "repr": "0x0000000000000000000000000000000000000000000000000000000000000002::coin::Coin<0x0000000000000000000000000000000000000000000000000000000000000002::iota::IOTA>" } } } @@ -200,7 +200,7 @@ Response: { "asMoveObject": { "contents": { "type": { - "repr": "0x0000000000000000000000000000000000000000000000000000000000000002::coin::Coin<0x0000000000000000000000000000000000000000000000000000000000000002::iota::IOTA>" + "repr": "0x0000000000000000000000000000000000000000000000000000000000000002::coin::CoinMetadata<0x0000000000000000000000000000000000000000000000000000000000000002::iota::IOTA>" } } } @@ -211,7 +211,7 @@ Response: { "asMoveObject": { "contents": { "type": { - "repr": "0x0000000000000000000000000000000000000000000000000000000000000002::coin::Coin<0x0000000000000000000000000000000000000000000000000000000000000002::iota::IOTA>" + "repr": "0x0000000000000000000000000000000000000000000000000000000000000002::dynamic_field::Field" } } } @@ -233,7 +233,7 @@ Response: { "asMoveObject": { "contents": { "type": { - "repr": "0x0000000000000000000000000000000000000000000000000000000000000002::dynamic_field::Field" + "repr": "0x0000000000000000000000000000000000000000000000000000000000000002::display::Display<0x000000000000000000000000000000000000000000000000000000000000107a::nft::Nft>" } } } @@ -244,7 +244,7 @@ Response: { "asMoveObject": { "contents": { "type": { - "repr": "0x0000000000000000000000000000000000000000000000000000000000000002::dynamic_field::Field<0x0000000000000000000000000000000000000000000000000000000000000002::object::ID,address>" + "repr": "0x0000000000000000000000000000000000000000000000000000000000000002::dynamic_field::Field" } } } @@ -255,7 +255,7 @@ Response: { "asMoveObject": { "contents": { "type": { - "repr": "0x0000000000000000000000000000000000000000000000000000000000000002::dynamic_field::Field" + "repr": "0x0000000000000000000000000000000000000000000000000000000000000002::dynamic_field::Field<0x0000000000000000000000000000000000000000000000000000000000000002::object::ID,address>" } } } @@ -288,7 +288,7 @@ Response: { "asMoveObject": { "contents": { "type": { - "repr": "0x0000000000000000000000000000000000000000000000000000000000000002::coin::CoinMetadata<0x0000000000000000000000000000000000000000000000000000000000000002::iota::IOTA>" + "repr": "0x0000000000000000000000000000000000000000000000000000000000000002::coin::Coin<0x0000000000000000000000000000000000000000000000000000000000000002::iota::IOTA>" } } } @@ -310,7 +310,7 @@ Response: { "asMoveObject": { "contents": { "type": { - "repr": "0x0000000000000000000000000000000000000000000000000000000000000002::coin::Coin<0x0000000000000000000000000000000000000000000000000000000000000002::iota::IOTA>" + "repr": "0x0000000000000000000000000000000000000000000000000000000000000002::coin::CoinMetadata<0x0000000000000000000000000000000000000000000000000000000000000002::iota::IOTA>" } } } diff --git a/crates/iota-graphql-e2e-tests/tests/objects/pagination.exp b/crates/iota-graphql-e2e-tests/tests/objects/pagination.exp index 1c7b0508d36..4da0d38ba55 100644 --- a/crates/iota-graphql-e2e-tests/tests/objects/pagination.exp +++ b/crates/iota-graphql-e2e-tests/tests/objects/pagination.exp @@ -48,19 +48,19 @@ Response: { "objects": { "edges": [ { - "cursor": "ICtsolfhSs84dlGvOImwI5jzXXQu2djMTh/gQQJgahXGAQAAAAAAAAA=" + "cursor": "ICz5IIuKI6+mzOyxS7vkE/oGAnCaqEDXuBATCd5LC5QvAQAAAAAAAAA=" }, { - "cursor": "IIt71raxnB/0N0g4+DWkvYCE3zMwk/e4DvXm1zFlJwt0AQAAAAAAAAA=" + "cursor": "IE/xhbQKpM+NlTQZ438Fzeh/2sIYYDkqr2aI4OBK3c4xAQAAAAAAAAA=" }, { - "cursor": "II5CZZLbHHjpLgtfdPqwkekv/h4PbtW2t3jDYeM1OLloAQAAAAAAAAA=" + "cursor": "IGHtIXjzidfc4B0Zn7TKECtr9BEfkMb34vC1w8RZgbDxAQAAAAAAAAA=" }, { - "cursor": "IJlUozzGeAqyGOEW+M5AEBV7mSeyEPC82WBdwBQh7krzAQAAAAAAAAA=" + "cursor": "IGxlkgg1Xn7VdPx43tX0JtmWgR+IlR9iL4dsHRBli/wmAQAAAAAAAAA=" }, { - "cursor": "IJsn9ZEZnNXewi7e86kFfZssa+oH496dRRxZR/uo6X0ZAQAAAAAAAAA=" + "cursor": "IKiO4X/plBakAGLB9F5txiGn/HSJGY5XSERR8R7x8jkTAQAAAAAAAAA=" } ] } @@ -76,10 +76,10 @@ Response: { "objects": { "edges": [ { - "cursor": "ICtsolfhSs84dlGvOImwI5jzXXQu2djMTh/gQQJgahXGAQAAAAAAAAA=" + "cursor": "ICz5IIuKI6+mzOyxS7vkE/oGAnCaqEDXuBATCd5LC5QvAQAAAAAAAAA=" }, { - "cursor": "IIt71raxnB/0N0g4+DWkvYCE3zMwk/e4DvXm1zFlJwt0AQAAAAAAAAA=" + "cursor": "IE/xhbQKpM+NlTQZ438Fzeh/2sIYYDkqr2aI4OBK3c4xAQAAAAAAAAA=" } ] } @@ -95,52 +95,52 @@ Response: { "objects": { "edges": [ { - "cursor": "ICtsolfhSs84dlGvOImwI5jzXXQu2djMTh/gQQJgahXGAQAAAAAAAAA=", + "cursor": "ICz5IIuKI6+mzOyxS7vkE/oGAnCaqEDXuBATCd5LC5QvAQAAAAAAAAA=", "node": { - "address": "0x2b6ca257e14acf387651af3889b02398f35d742ed9d8cc4e1fe04102606a15c6" + "address": "0x2cf9208b8a23afa6ccecb14bbbe413fa0602709aa840d7b8101309de4b0b942f" } }, { - "cursor": "IIt71raxnB/0N0g4+DWkvYCE3zMwk/e4DvXm1zFlJwt0AQAAAAAAAAA=", + "cursor": "IE/xhbQKpM+NlTQZ438Fzeh/2sIYYDkqr2aI4OBK3c4xAQAAAAAAAAA=", "node": { - "address": "0x8b7bd6b6b19c1ff4374838f835a4bd8084df333093f7b80ef5e6d73165270b74" + "address": "0x4ff185b40aa4cf8d953419e37f05cde87fdac21860392aaf6688e0e04addce31" } }, { - "cursor": "II5CZZLbHHjpLgtfdPqwkekv/h4PbtW2t3jDYeM1OLloAQAAAAAAAAA=", + "cursor": "IGHtIXjzidfc4B0Zn7TKECtr9BEfkMb34vC1w8RZgbDxAQAAAAAAAAA=", "node": { - "address": "0x8e426592db1c78e92e0b5f74fab091e92ffe1e0f6ed5b6b778c361e33538b968" + "address": "0x61ed2178f389d7dce01d199fb4ca102b6bf4111f90c6f7e2f0b5c3c45981b0f1" } }, { - "cursor": "IJlUozzGeAqyGOEW+M5AEBV7mSeyEPC82WBdwBQh7krzAQAAAAAAAAA=", + "cursor": "IGxlkgg1Xn7VdPx43tX0JtmWgR+IlR9iL4dsHRBli/wmAQAAAAAAAAA=", "node": { - "address": "0x9954a33cc6780ab218e116f8ce4010157b9927b210f0bcd9605dc01421ee4af3" + "address": "0x6c659208355e7ed574fc78ded5f426d996811f88951f622f876c1d10658bfc26" } }, { - "cursor": "IJsn9ZEZnNXewi7e86kFfZssa+oH496dRRxZR/uo6X0ZAQAAAAAAAAA=", + "cursor": "IKiO4X/plBakAGLB9F5txiGn/HSJGY5XSERR8R7x8jkTAQAAAAAAAAA=", "node": { - "address": "0x9b27f591199cd5dec22edef3a9057d9b2c6bea07e3de9d451c5947fba8e97d19" + "address": "0xa88ee17fe99416a40062c1f45e6dc621a7fc7489198e57484451f11ef1f23913" } } ] } }, "obj_3_0": { - "address": "0x8b7bd6b6b19c1ff4374838f835a4bd8084df333093f7b80ef5e6d73165270b74" + "address": "0x2cf9208b8a23afa6ccecb14bbbe413fa0602709aa840d7b8101309de4b0b942f" }, "obj_5_0": { - "address": "0x9954a33cc6780ab218e116f8ce4010157b9927b210f0bcd9605dc01421ee4af3" + "address": "0x61ed2178f389d7dce01d199fb4ca102b6bf4111f90c6f7e2f0b5c3c45981b0f1" }, "obj_6_0": { - "address": "0x9b27f591199cd5dec22edef3a9057d9b2c6bea07e3de9d451c5947fba8e97d19" + "address": "0x4ff185b40aa4cf8d953419e37f05cde87fdac21860392aaf6688e0e04addce31" }, "obj_4_0": { - "address": "0x8e426592db1c78e92e0b5f74fab091e92ffe1e0f6ed5b6b778c361e33538b968" + "address": "0x6c659208355e7ed574fc78ded5f426d996811f88951f622f876c1d10658bfc26" }, "obj_2_0": { - "address": "0x2b6ca257e14acf387651af3889b02398f35d742ed9d8cc4e1fe04102606a15c6" + "address": "0xa88ee17fe99416a40062c1f45e6dc621a7fc7489198e57484451f11ef1f23913" } } } @@ -153,7 +153,10 @@ Response: { "objects": { "edges": [ { - "cursor": "IJsn9ZEZnNXewi7e86kFfZssa+oH496dRRxZR/uo6X0ZAQAAAAAAAAA=" + "cursor": "IGxlkgg1Xn7VdPx43tX0JtmWgR+IlR9iL4dsHRBli/wmAQAAAAAAAAA=" + }, + { + "cursor": "IKiO4X/plBakAGLB9F5txiGn/HSJGY5XSERR8R7x8jkTAQAAAAAAAAA=" } ] } @@ -169,7 +172,7 @@ Response: { "objects": { "edges": [ { - "cursor": "IJlUozzGeAqyGOEW+M5AEBV7mSeyEPC82WBdwBQh7krzAQAAAAAAAAA=" + "cursor": "IKiO4X/plBakAGLB9F5txiGn/HSJGY5XSERR8R7x8jkTAQAAAAAAAAA=" } ] } @@ -183,11 +186,7 @@ Response: { "data": { "address": { "objects": { - "edges": [ - { - "cursor": "ICtsolfhSs84dlGvOImwI5jzXXQu2djMTh/gQQJgahXGAQAAAAAAAAA=" - } - ] + "edges": [] } } } @@ -201,15 +200,15 @@ Response: { "objects": { "edges": [ { - "cursor": "IJlUozzGeAqyGOEW+M5AEBV7mSeyEPC82WBdwBQh7krzAQAAAAAAAAA=", + "cursor": "IGxlkgg1Xn7VdPx43tX0JtmWgR+IlR9iL4dsHRBli/wmAQAAAAAAAAA=", "node": { - "address": "0x9954a33cc6780ab218e116f8ce4010157b9927b210f0bcd9605dc01421ee4af3" + "address": "0x6c659208355e7ed574fc78ded5f426d996811f88951f622f876c1d10658bfc26" } }, { - "cursor": "IJsn9ZEZnNXewi7e86kFfZssa+oH496dRRxZR/uo6X0ZAQAAAAAAAAA=", + "cursor": "IKiO4X/plBakAGLB9F5txiGn/HSJGY5XSERR8R7x8jkTAQAAAAAAAAA=", "node": { - "address": "0x9b27f591199cd5dec22edef3a9057d9b2c6bea07e3de9d451c5947fba8e97d19" + "address": "0xa88ee17fe99416a40062c1f45e6dc621a7fc7489198e57484451f11ef1f23913" } } ] diff --git a/crates/iota-graphql-e2e-tests/tests/objects/public_transfer.exp b/crates/iota-graphql-e2e-tests/tests/objects/public_transfer.exp index 59da6a2004d..8a47d32ffcf 100644 --- a/crates/iota-graphql-e2e-tests/tests/objects/public_transfer.exp +++ b/crates/iota-graphql-e2e-tests/tests/objects/public_transfer.exp @@ -37,10 +37,10 @@ Response: { "asMoveObject": { "contents": { "type": { - "repr": "0x24c656fc76e9147ca76a3d20b7933a417a10714e9c32360ba95aaac0407d6a7b::m::Foo" + "repr": "0xe5b2eaebcea299e2a55ee5d2daebb15e71f47ed83ea0e9702359e55f26a6da0d::m::Bar" } }, - "hasPublicTransfer": true + "hasPublicTransfer": false } } }, @@ -61,10 +61,10 @@ Response: { "asMoveObject": { "contents": { "type": { - "repr": "0x24c656fc76e9147ca76a3d20b7933a417a10714e9c32360ba95aaac0407d6a7b::m::Bar" + "repr": "0xe5b2eaebcea299e2a55ee5d2daebb15e71f47ed83ea0e9702359e55f26a6da0d::m::Foo" } }, - "hasPublicTransfer": false + "hasPublicTransfer": true } } } diff --git a/crates/iota-graphql-e2e-tests/tests/objects/received.exp b/crates/iota-graphql-e2e-tests/tests/objects/received.exp index ccd85baf2ed..649207f54ac 100644 --- a/crates/iota-graphql-e2e-tests/tests/objects/received.exp +++ b/crates/iota-graphql-e2e-tests/tests/objects/received.exp @@ -30,7 +30,7 @@ Response: { "receivedTransactionBlocks": { "nodes": [ { - "digest": "HKYdrd3SigjtyshocUcpngqrcEHd5bLE7a5PuqopsEp6" + "digest": "BpQiF9UpsqLzSanNFGVvRXjcn5nPVUukaiQiRZFKXkEn" } ] } diff --git a/crates/iota-graphql-e2e-tests/tests/objects/staked_iota.exp b/crates/iota-graphql-e2e-tests/tests/objects/staked_iota.exp index a4d3ec518fa..5656d2d4726 100644 --- a/crates/iota-graphql-e2e-tests/tests/objects/staked_iota.exp +++ b/crates/iota-graphql-e2e-tests/tests/objects/staked_iota.exp @@ -10,7 +10,7 @@ Response: { "objects": { "edges": [ { - "cursor": "IL6XFugQ26bu+xGPneNsvxIrMLQoA3owT5H4f3zHNuXIAAAAAAAAAAA=", + "cursor": "IFH/uNA0p9hgv8vtgPYPhPx5vPpLjK+laCIv3sJLgxmZAAAAAAAAAAA=", "node": { "asMoveObject": { "asStakedIota": { @@ -39,11 +39,11 @@ gas summary: computation_cost: 1000000, storage_cost: 1976000, storage_rebate: task 3, line 38: //# run 0x3::iota_system::request_add_stake --args object(0x5) object(2,0) @validator_0 --sender C -events: Event { package_id: iota_system, transaction_module: Identifier("iota_system"), sender: C, type_: StructTag { address: iota_system, module: Identifier("validator"), name: Identifier("StakingRequestEvent"), type_params: [] }, contents: [171, 56, 174, 116, 116, 231, 90, 122, 148, 80, 189, 213, 3, 8, 47, 190, 80, 171, 87, 32, 84, 9, 231, 203, 82, 3, 186, 181, 58, 235, 194, 1, 175, 163, 158, 79, 0, 218, 226, 120, 249, 119, 199, 198, 147, 10, 94, 44, 118, 232, 93, 23, 165, 38, 215, 36, 187, 206, 15, 184, 31, 176, 125, 76, 140, 202, 78, 28, 224, 186, 89, 4, 206, 166, 29, 249, 36, 45, 162, 247, 210, 158, 62, 243, 40, 251, 126, 192, 124, 8, 107, 59, 244, 124, 166, 26, 0, 0, 0, 0, 0, 0, 0, 0, 0, 228, 11, 84, 2, 0, 0, 0] } -created: object(3,0), object(3,1) -mutated: 0x0000000000000000000000000000000000000000000000000000000000000005, object(0,0) -deleted: object(_), object(2,0) -gas summary: computation_cost: 1000000, storage_cost: 14561600, storage_rebate: 1976000, non_refundable_storage_fee: 0 +events: Event { package_id: iota_system, transaction_module: Identifier("iota_system"), sender: C, type_: StructTag { address: iota_system, module: Identifier("validator"), name: Identifier("StakingRequestEvent"), type_params: [] }, contents: [135, 213, 224, 32, 91, 207, 0, 187, 34, 183, 14, 41, 167, 78, 77, 75, 138, 89, 173, 167, 170, 11, 38, 100, 45, 178, 245, 162, 113, 72, 177, 240, 175, 163, 158, 79, 0, 218, 226, 120, 249, 119, 199, 198, 147, 10, 94, 44, 118, 232, 93, 23, 165, 38, 215, 36, 187, 206, 15, 184, 31, 176, 125, 76, 140, 202, 78, 28, 224, 186, 89, 4, 206, 166, 29, 249, 36, 45, 162, 247, 210, 158, 62, 243, 40, 251, 126, 192, 124, 8, 107, 59, 244, 124, 166, 26, 0, 0, 0, 0, 0, 0, 0, 0, 0, 228, 11, 84, 2, 0, 0, 0] } +created: object(3,0) +mutated: object(_), 0x0000000000000000000000000000000000000000000000000000000000000005, object(0,0) +deleted: object(2,0) +gas summary: computation_cost: 1000000, storage_cost: 14523600, storage_rebate: 1976000, non_refundable_storage_fee: 0 task 4, line 40: //# create-checkpoint @@ -60,34 +60,34 @@ Response: { "objects": { "edges": [ { - "cursor": "ICyVnatyIW8BBQyropcZeyQEQxpFiSDIk5mD/WFlco2wAgAAAAAAAAA=", + "cursor": "IBI4Fo2NYBQFmwjdXvYZPRT977qOK/lqUGGG1hDgb5pdAgAAAAAAAAA=", "node": { "asMoveObject": { "asStakedIota": { "principal": "10000000000", - "poolId": "0xab38ae7474e75a7a9450bdd503082fbe50ab57205409e7cb5203bab53aebc201" + "poolId": "0x87d5e0205bcf00bb22b70e29a74e4d4b8a59ada7aa0b26642db2f5a27148b1f0" } } } }, { - "cursor": "IL6XFugQ26bu+xGPneNsvxIrMLQoA3owT5H4f3zHNuXIAgAAAAAAAAA=", + "cursor": "IFH/uNA0p9hgv8vtgPYPhPx5vPpLjK+laCIv3sJLgxmZAgAAAAAAAAA=", "node": { "asMoveObject": { "asStakedIota": { "principal": "1500000000000000", - "poolId": "0xab38ae7474e75a7a9450bdd503082fbe50ab57205409e7cb5203bab53aebc201" + "poolId": "0x87d5e0205bcf00bb22b70e29a74e4d4b8a59ada7aa0b26642db2f5a27148b1f0" } } } }, { - "cursor": "IMqZuQSI1P4/w7vGb7cegyAhP7MlN0wtU6CPLPVuQweKAgAAAAAAAAA=", + "cursor": "ILVYziRMbmfeQ0alyypl2nA4gTpsnVI0/mNu+O2M0UcwAgAAAAAAAAA=", "node": { "asMoveObject": { "asStakedIota": { "principal": "15340000000000", - "poolId": "0xab38ae7474e75a7a9450bdd503082fbe50ab57205409e7cb5203bab53aebc201" + "poolId": "0x87d5e0205bcf00bb22b70e29a74e4d4b8a59ada7aa0b26642db2f5a27148b1f0" } } } @@ -98,7 +98,7 @@ Response: { "stakedIotas": { "edges": [ { - "cursor": "ICyVnatyIW8BBQyropcZeyQEQxpFiSDIk5mD/WFlco2wAgAAAAAAAAA=", + "cursor": "IBI4Fo2NYBQFmwjdXvYZPRT977qOK/lqUGGG1hDgb5pdAgAAAAAAAAA=", "node": { "principal": "10000000000" } diff --git a/crates/iota-graphql-e2e-tests/tests/owner/downcasts.exp b/crates/iota-graphql-e2e-tests/tests/owner/downcasts.exp index 9128df7e650..29fa37b8ea8 100644 --- a/crates/iota-graphql-e2e-tests/tests/owner/downcasts.exp +++ b/crates/iota-graphql-e2e-tests/tests/owner/downcasts.exp @@ -24,7 +24,7 @@ Response: { }, "coin": { "asObject": { - "digest": "5vRWjBz8CXM1nbBRud4xQLkHPa5hUfomnTs2Vbc6PruV" + "digest": "DFtexsvNVh4PmwAiXnx9kSN976yuTwfcScCVFSWttNpb" } } } diff --git a/crates/iota-graphql-e2e-tests/tests/owner/root_version.exp b/crates/iota-graphql-e2e-tests/tests/owner/root_version.exp index 07ae68efadb..2b944182393 100644 --- a/crates/iota-graphql-e2e-tests/tests/owner/root_version.exp +++ b/crates/iota-graphql-e2e-tests/tests/owner/root_version.exp @@ -124,10 +124,10 @@ Response: { "version": 11, "contents": { "json": { - "id": "0x7f25c843015b0ca01a7bb3d5c433ed7a925ebf816889a33039b4c01ef1d57a55", + "id": "0xdadd6b40653df07306e4bbd806c5d91cdfd309e195e5c4247e8583dafd5d4887", "count": "1", "wrapped": { - "id": "0x18000440516999a85b3bdf516c720df29f7a858360de51f4178a7232f5460cdc", + "id": "0x5d4aba4106cbb800784bc62b281859da27d7f76dc232970dc09af09773b146f8", "count": "1" } } @@ -141,10 +141,10 @@ Response: { "version": 10, "contents": { "json": { - "id": "0x7f25c843015b0ca01a7bb3d5c433ed7a925ebf816889a33039b4c01ef1d57a55", + "id": "0xdadd6b40653df07306e4bbd806c5d91cdfd309e195e5c4247e8583dafd5d4887", "count": "1", "wrapped": { - "id": "0x18000440516999a85b3bdf516c720df29f7a858360de51f4178a7232f5460cdc", + "id": "0x5d4aba4106cbb800784bc62b281859da27d7f76dc232970dc09af09773b146f8", "count": "1" } } @@ -158,10 +158,10 @@ Response: { "version": 8, "contents": { "json": { - "id": "0x7f25c843015b0ca01a7bb3d5c433ed7a925ebf816889a33039b4c01ef1d57a55", + "id": "0xdadd6b40653df07306e4bbd806c5d91cdfd309e195e5c4247e8583dafd5d4887", "count": "1", "wrapped": { - "id": "0x18000440516999a85b3bdf516c720df29f7a858360de51f4178a7232f5460cdc", + "id": "0x5d4aba4106cbb800784bc62b281859da27d7f76dc232970dc09af09773b146f8", "count": "0" } } @@ -175,10 +175,10 @@ Response: { "version": 7, "contents": { "json": { - "id": "0x7f25c843015b0ca01a7bb3d5c433ed7a925ebf816889a33039b4c01ef1d57a55", + "id": "0xdadd6b40653df07306e4bbd806c5d91cdfd309e195e5c4247e8583dafd5d4887", "count": "0", "wrapped": { - "id": "0x18000440516999a85b3bdf516c720df29f7a858360de51f4178a7232f5460cdc", + "id": "0x5d4aba4106cbb800784bc62b281859da27d7f76dc232970dc09af09773b146f8", "count": "0" } } @@ -199,7 +199,7 @@ Response: { "version": 7, "contents": { "json": { - "id": "0x521959664b50a297d21c5d2adca1265cf0fceecdc1082262335b9fb681294d99", + "id": "0xa7c0ba87883d6f3a62e844b3a0dd06063d2e2ae5cc2cd5fb51552cab1e91fa9c", "count": "0" } } @@ -212,7 +212,7 @@ Response: { "version": 10, "contents": { "json": { - "id": "0x521959664b50a297d21c5d2adca1265cf0fceecdc1082262335b9fb681294d99", + "id": "0xa7c0ba87883d6f3a62e844b3a0dd06063d2e2ae5cc2cd5fb51552cab1e91fa9c", "count": "1" } } @@ -225,7 +225,7 @@ Response: { "version": 10, "contents": { "json": { - "id": "0x521959664b50a297d21c5d2adca1265cf0fceecdc1082262335b9fb681294d99", + "id": "0xa7c0ba87883d6f3a62e844b3a0dd06063d2e2ae5cc2cd5fb51552cab1e91fa9c", "count": "1" } } @@ -238,7 +238,7 @@ Response: { "version": 7, "contents": { "json": { - "id": "0x521959664b50a297d21c5d2adca1265cf0fceecdc1082262335b9fb681294d99", + "id": "0xa7c0ba87883d6f3a62e844b3a0dd06063d2e2ae5cc2cd5fb51552cab1e91fa9c", "count": "0" } } @@ -251,7 +251,7 @@ Response: { "version": 7, "contents": { "json": { - "id": "0x521959664b50a297d21c5d2adca1265cf0fceecdc1082262335b9fb681294d99", + "id": "0xa7c0ba87883d6f3a62e844b3a0dd06063d2e2ae5cc2cd5fb51552cab1e91fa9c", "count": "0" } } @@ -271,7 +271,7 @@ Response: { "version": 7, "contents": { "json": { - "id": "0x89fde96c1fe78bfc82af2bdaeba88cf217b22cb5574d6472080033d2c40ff796", + "id": "0xe29b50f8b9200699909adda56f8879b2423ccd71f8ce52834b5f411d07245094", "count": "0" } } @@ -284,7 +284,7 @@ Response: { "version": 11, "contents": { "json": { - "id": "0x89fde96c1fe78bfc82af2bdaeba88cf217b22cb5574d6472080033d2c40ff796", + "id": "0xe29b50f8b9200699909adda56f8879b2423ccd71f8ce52834b5f411d07245094", "count": "1" } } @@ -297,7 +297,7 @@ Response: { "version": 7, "contents": { "json": { - "id": "0x89fde96c1fe78bfc82af2bdaeba88cf217b22cb5574d6472080033d2c40ff796", + "id": "0xe29b50f8b9200699909adda56f8879b2423ccd71f8ce52834b5f411d07245094", "count": "0" } } diff --git a/crates/iota-graphql-e2e-tests/tests/packages/datatypes.exp b/crates/iota-graphql-e2e-tests/tests/packages/datatypes.exp index b747718aa6d..1344bdab0eb 100644 --- a/crates/iota-graphql-e2e-tests/tests/packages/datatypes.exp +++ b/crates/iota-graphql-e2e-tests/tests/packages/datatypes.exp @@ -155,7 +155,7 @@ task 5, lines 73-97: Response: { "data": { "object": { - "address": "0x5ce5f3dd044a95427557b25105b6970a0d777788331b6805c0b444d7c984c5c5", + "address": "0x84bade4e1affc5ca662106640dd8d01946dc34586f44685ee43bb9e8f7745491", "asMovePackage": { "module": { "datatypes": { @@ -190,7 +190,7 @@ task 6, lines 99-144: Response: { "data": { "object": { - "address": "0x5ce5f3dd044a95427557b25105b6970a0d777788331b6805c0b444d7c984c5c5", + "address": "0x84bade4e1affc5ca662106640dd8d01946dc34586f44685ee43bb9e8f7745491", "asMovePackage": { "module": { "datatypes": { diff --git a/crates/iota-graphql-e2e-tests/tests/packages/enums.exp b/crates/iota-graphql-e2e-tests/tests/packages/enums.exp index e521f6045ad..817b0132c97 100644 --- a/crates/iota-graphql-e2e-tests/tests/packages/enums.exp +++ b/crates/iota-graphql-e2e-tests/tests/packages/enums.exp @@ -25,19 +25,19 @@ Response: { "nodes": [ { "outputState": { - "address": "0x16a8e888439fb865e2ebb65d890e872be6717414f401f079b5741e67467ca41c", + "address": "0x5c053df0f3ff451996d97f922275b6b12236fbb823340f82c46a83bd7ecc32ac", "asMovePackage": null } }, { "outputState": { - "address": "0x88753f8821c7d5b8e634264999e593f39e15cb68e4814abd86a995e8c88746e9", + "address": "0x5c1292f982e4f4162d6bda7f92177d35c6d0cfbb5b5317a91269d060fb7aa7af", "asMovePackage": null } }, { "outputState": { - "address": "0xdc6634b155a40eb697bff23f384ba7e04a70a9772e88c44ba983327437c66db6", + "address": "0xf6c427b747bb3014e8773e17875f8948c8b328380c5093de76524dfbda4888a0", "asMovePackage": { "module": { "enum": { @@ -125,19 +125,13 @@ Response: { "nodes": [ { "outputState": { - "address": "0x16a8e888439fb865e2ebb65d890e872be6717414f401f079b5741e67467ca41c", - "asMovePackage": null - } - }, - { - "outputState": { - "address": "0x4f420f2f6ae06a6f316000f71001cd4de755380770f0a31ff05c77b9f753875c", + "address": "0x249e61be7cd170f441f4496b19a5c5fe6ba62c2da158d464822c736f48c30b13", "asMovePackage": { "module": { "s": { "module": { "package": { - "address": "0xdc6634b155a40eb697bff23f384ba7e04a70a9772e88c44ba983327437c66db6" + "address": "0xf6c427b747bb3014e8773e17875f8948c8b328380c5093de76524dfbda4888a0" } }, "name": "S", @@ -192,7 +186,7 @@ Response: { "t": { "module": { "package": { - "address": "0x4f420f2f6ae06a6f316000f71001cd4de755380770f0a31ff05c77b9f753875c" + "address": "0x249e61be7cd170f441f4496b19a5c5fe6ba62c2da158d464822c736f48c30b13" } }, "name": "T", @@ -222,12 +216,12 @@ Response: { { "name": "s", "type": { - "repr": "0xdc6634b155a40eb697bff23f384ba7e04a70a9772e88c44ba983327437c66db6::m::S", + "repr": "0xf6c427b747bb3014e8773e17875f8948c8b328380c5093de76524dfbda4888a0::m::S", "signature": { "ref": null, "body": { "datatype": { - "package": "0xdc6634b155a40eb697bff23f384ba7e04a70a9772e88c44ba983327437c66db6", + "package": "0xf6c427b747bb3014e8773e17875f8948c8b328380c5093de76524dfbda4888a0", "module": "m", "type": "S", "typeParameters": [] @@ -261,7 +255,7 @@ Response: { { "name": "t", "type": { - "repr": "0xdc6634b155a40eb697bff23f384ba7e04a70a9772e88c44ba983327437c66db6::m::T<0xdc6634b155a40eb697bff23f384ba7e04a70a9772e88c44ba983327437c66db6::m::S>" + "repr": "0xf6c427b747bb3014e8773e17875f8948c8b328380c5093de76524dfbda4888a0::m::T<0xf6c427b747bb3014e8773e17875f8948c8b328380c5093de76524dfbda4888a0::m::S>" } } ] @@ -274,7 +268,13 @@ Response: { }, { "outputState": { - "address": "0x88753f8821c7d5b8e634264999e593f39e15cb68e4814abd86a995e8c88746e9", + "address": "0x5c053df0f3ff451996d97f922275b6b12236fbb823340f82c46a83bd7ecc32ac", + "asMovePackage": null + } + }, + { + "outputState": { + "address": "0x5c1292f982e4f4162d6bda7f92177d35c6d0cfbb5b5317a91269d060fb7aa7af", "asMovePackage": null } } @@ -297,11 +297,6 @@ Response: { "effects": { "objectChanges": { "nodes": [ - { - "outputState": { - "asMovePackage": null - } - }, { "outputState": { "asMovePackage": { @@ -322,6 +317,11 @@ Response: { } } }, + { + "outputState": { + "asMovePackage": null + } + }, { "outputState": { "asMovePackage": null diff --git a/crates/iota-graphql-e2e-tests/tests/packages/friends.exp b/crates/iota-graphql-e2e-tests/tests/packages/friends.exp index b19c3041ef6..579783ff716 100644 --- a/crates/iota-graphql-e2e-tests/tests/packages/friends.exp +++ b/crates/iota-graphql-e2e-tests/tests/packages/friends.exp @@ -23,16 +23,6 @@ Response: { "effects": { "objectChanges": { "nodes": [ - { - "outputState": { - "asMovePackage": null - } - }, - { - "outputState": { - "asMovePackage": null - } - }, { "outputState": { "asMovePackage": { @@ -106,6 +96,16 @@ Response: { } } } + }, + { + "outputState": { + "asMovePackage": null + } + }, + { + "outputState": { + "asMovePackage": null + } } ] } @@ -128,7 +128,9 @@ Response: { "nodes": [ { "outputState": { - "asMovePackage": null + "asMovePackage": { + "module": null + } } }, { @@ -138,9 +140,7 @@ Response: { }, { "outputState": { - "asMovePackage": { - "module": null - } + "asMovePackage": null } } ] @@ -166,7 +166,7 @@ Response: { "effects", "objectChanges", "nodes", - 2, + 0, "outputState", "asMovePackage", "module", @@ -189,16 +189,6 @@ Response: { "effects": { "objectChanges": { "nodes": [ - { - "outputState": { - "asMovePackage": null - } - }, - { - "outputState": { - "asMovePackage": null - } - }, { "outputState": { "asMovePackage": { @@ -274,6 +264,16 @@ Response: { } } } + }, + { + "outputState": { + "asMovePackage": null + } + }, + { + "outputState": { + "asMovePackage": null + } } ] } @@ -304,16 +304,6 @@ Response: { "effects": { "objectChanges": { "nodes": [ - { - "outputState": { - "asMovePackage": null - } - }, - { - "outputState": { - "asMovePackage": null - } - }, { "outputState": { "asMovePackage": { @@ -349,6 +339,16 @@ Response: { } } } + }, + { + "outputState": { + "asMovePackage": null + } + }, + { + "outputState": { + "asMovePackage": null + } } ] } diff --git a/crates/iota-graphql-e2e-tests/tests/packages/functions.exp b/crates/iota-graphql-e2e-tests/tests/packages/functions.exp index 58481617aa2..7c560a5a2be 100644 --- a/crates/iota-graphql-e2e-tests/tests/packages/functions.exp +++ b/crates/iota-graphql-e2e-tests/tests/packages/functions.exp @@ -95,19 +95,13 @@ Response: { "nodes": [ { "outputState": { - "address": "0x16a8e888439fb865e2ebb65d890e872be6717414f401f079b5741e67467ca41c", - "asMovePackage": null - } - }, - { - "outputState": { - "address": "0x4f02b282959db3d0b3c34ee9be4bd8e39023b8cf1a1a069e14325e650672b480", + "address": "0x143c64eb9d9ba9a32499ffa73ffd8da7d72b21706889c058ca4f71e0d30f2e1f", "asMovePackage": { "module": { "function": { "module": { "package": { - "address": "0x4f02b282959db3d0b3c34ee9be4bd8e39023b8cf1a1a069e14325e650672b480" + "address": "0x143c64eb9d9ba9a32499ffa73ffd8da7d72b21706889c058ca4f71e0d30f2e1f" } }, "name": "f", @@ -140,7 +134,13 @@ Response: { }, { "outputState": { - "address": "0xd3ca42aff193387adecc01129e9e6444616c5d57c065e118dbff9e7e0d3f6f96", + "address": "0x5c1292f982e4f4162d6bda7f92177d35c6d0cfbb5b5317a91269d060fb7aa7af", + "asMovePackage": null + } + }, + { + "outputState": { + "address": "0x96f187369f9ad2d57c174ff79d8f830291b8e0288ac452c880366143fd1a69b8", "asMovePackage": null } } @@ -175,19 +175,25 @@ Response: { "nodes": [ { "outputState": { - "address": "0x16a8e888439fb865e2ebb65d890e872be6717414f401f079b5741e67467ca41c", + "address": "0x5c1292f982e4f4162d6bda7f92177d35c6d0cfbb5b5317a91269d060fb7aa7af", "asMovePackage": null } }, { "outputState": { - "address": "0x40aee5b33d9247ebd2df3db5644ee494dff36c45c2fd6b550e9a0701bf9f00f6", + "address": "0x96f187369f9ad2d57c174ff79d8f830291b8e0288ac452c880366143fd1a69b8", + "asMovePackage": null + } + }, + { + "outputState": { + "address": "0xac73467442fd42c2afe65f52bc3011c63f887fbbe0d41ce241c5b5be43c706b2", "asMovePackage": { "module": { "f": { "module": { "package": { - "address": "0x40aee5b33d9247ebd2df3db5644ee494dff36c45c2fd6b550e9a0701bf9f00f6" + "address": "0xac73467442fd42c2afe65f52bc3011c63f887fbbe0d41ce241c5b5be43c706b2" } }, "name": "f", @@ -217,7 +223,7 @@ Response: { "g": { "module": { "package": { - "address": "0x40aee5b33d9247ebd2df3db5644ee494dff36c45c2fd6b550e9a0701bf9f00f6" + "address": "0xac73467442fd42c2afe65f52bc3011c63f887fbbe0d41ce241c5b5be43c706b2" } }, "name": "g", @@ -234,12 +240,6 @@ Response: { } } } - }, - { - "outputState": { - "address": "0xd3ca42aff193387adecc01129e9e6444616c5d57c065e118dbff9e7e0d3f6f96", - "asMovePackage": null - } } ] } diff --git a/crates/iota-graphql-e2e-tests/tests/packages/modules.exp b/crates/iota-graphql-e2e-tests/tests/packages/modules.exp index 60291c7367e..18857f26ed4 100644 --- a/crates/iota-graphql-e2e-tests/tests/packages/modules.exp +++ b/crates/iota-graphql-e2e-tests/tests/packages/modules.exp @@ -22,23 +22,23 @@ Response: { "nodes": [ { "outputState": { - "address": "0x00abce450bda0ce7092d4c8930eaedf884ee0cb4584bf840e8f8950aa50de247", + "address": "0x71c9cabc936c3a8f4d713575c2455982c03e5bf0acd1f6b2ee64befacf669e20", "asMovePackage": { "module": { "name": "m", "package": { - "address": "0x00abce450bda0ce7092d4c8930eaedf884ee0cb4584bf840e8f8950aa50de247" + "address": "0x71c9cabc936c3a8f4d713575c2455982c03e5bf0acd1f6b2ee64befacf669e20" }, "fileFormatVersion": 6, - "bytes": "oRzrCwYAAAAIAQAGAgYKAxARBCEEBSUfB0QkCGhADKgBMAAGAQMBBQEADAEAAQIBAgAABAABAQIAAgIBAAEHBQEBAAIEAAYCAwYLAAEJAAEDAQYLAAEIAQABCQABBgsAAQkAAQgBBENvaW4ESU9UQQNiYXIEY29pbgNmb28EaW90YQFtBXZhbHVlAKvORQvaDOcJLUyJMOrt+ITuDLRYS/hA6PiVCqUN4kcAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAgABAAADBQsBOAALABYCAQEAAAMIBioAAAAAAAAACgA4AQYrAAAAAAAAAAsAOAEYAgA=", - "disassembly": "// Move bytecode v6\nmodule abce450bda0ce7092d4c8930eaedf884ee0cb4584bf840e8f8950aa50de247.m {\nuse 0000000000000000000000000000000000000000000000000000000000000002::coin;\nuse 0000000000000000000000000000000000000000000000000000000000000002::iota;\n\n\n\n\n\n\npublic foo(Arg0: u64, Arg1: &Coin): u64 {\nB0:\n\t0: MoveLoc[1](Arg1: &Coin)\n\t1: Call coin::value(&Coin): u64\n\t2: MoveLoc[0](Arg0: u64)\n\t3: Add\n\t4: Ret\n\n}\npublic bar(Arg0: &Coin): u64 {\nB0:\n\t0: LdU64(42)\n\t1: CopyLoc[0](Arg0: &Coin)\n\t2: Call foo(u64, &Coin): u64\n\t3: LdU64(43)\n\t4: MoveLoc[0](Arg0: &Coin)\n\t5: Call foo(u64, &Coin): u64\n\t6: Mul\n\t7: Ret\n\n}\n}" + "bytes": "oRzrCwYAAAAIAQAGAgYKAxARBCEEBSUfB0QkCGhADKgBMAAGAQMBBQEADAEAAQIBAgAABAABAQIAAgIBAAEHBQEBAAIEAAYCAwYLAAEJAAEDAQYLAAEIAQABCQABBgsAAQkAAQgBBENvaW4ESU9UQQNiYXIEY29pbgNmb28EaW90YQFtBXZhbHVlccnKvJNsOo9NcTV1wkVZgsA+W/Cs0fay7mS++s9mniAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAgABAAADBQsBOAALABYCAQEAAAMIBioAAAAAAAAACgA4AQYrAAAAAAAAAAsAOAEYAgA=", + "disassembly": "// Move bytecode v6\nmodule 71c9cabc936c3a8f4d713575c2455982c03e5bf0acd1f6b2ee64befacf669e20.m {\nuse 0000000000000000000000000000000000000000000000000000000000000002::coin;\nuse 0000000000000000000000000000000000000000000000000000000000000002::iota;\n\n\n\n\n\n\npublic foo(Arg0: u64, Arg1: &Coin): u64 {\nB0:\n\t0: MoveLoc[1](Arg1: &Coin)\n\t1: Call coin::value(&Coin): u64\n\t2: MoveLoc[0](Arg0: u64)\n\t3: Add\n\t4: Ret\n\n}\npublic bar(Arg0: &Coin): u64 {\nB0:\n\t0: LdU64(42)\n\t1: CopyLoc[0](Arg0: &Coin)\n\t2: Call foo(u64, &Coin): u64\n\t3: LdU64(43)\n\t4: MoveLoc[0](Arg0: &Coin)\n\t5: Call foo(u64, &Coin): u64\n\t6: Mul\n\t7: Ret\n\n}\n}" } } } }, { "outputState": { - "address": "0xc22d782d6b686022721c7a680612c20817b6cad04210f7df35e471dfd78881f8", + "address": "0xa6544a66698c9baad5259e89ee9858db835ed8f099bc032fbfcb1f73e8377ae8", "asMovePackage": null } } @@ -63,7 +63,7 @@ Response: { "nodes": [ { "outputState": { - "address": "0x00abce450bda0ce7092d4c8930eaedf884ee0cb4584bf840e8f8950aa50de247", + "address": "0x71c9cabc936c3a8f4d713575c2455982c03e5bf0acd1f6b2ee64befacf669e20", "asMovePackage": { "all": { "edges": [ @@ -136,7 +136,7 @@ Response: { }, { "outputState": { - "address": "0xc22d782d6b686022721c7a680612c20817b6cad04210f7df35e471dfd78881f8", + "address": "0xa6544a66698c9baad5259e89ee9858db835ed8f099bc032fbfcb1f73e8377ae8", "asMovePackage": null } } @@ -161,7 +161,7 @@ Response: { "nodes": [ { "outputState": { - "address": "0x00abce450bda0ce7092d4c8930eaedf884ee0cb4584bf840e8f8950aa50de247", + "address": "0x71c9cabc936c3a8f4d713575c2455982c03e5bf0acd1f6b2ee64befacf669e20", "asMovePackage": { "prefix": { "edges": [ @@ -276,7 +276,7 @@ Response: { }, { "outputState": { - "address": "0xc22d782d6b686022721c7a680612c20817b6cad04210f7df35e471dfd78881f8", + "address": "0xa6544a66698c9baad5259e89ee9858db835ed8f099bc032fbfcb1f73e8377ae8", "asMovePackage": null } } diff --git a/crates/iota-graphql-e2e-tests/tests/packages/structs.exp b/crates/iota-graphql-e2e-tests/tests/packages/structs.exp index 1c7016391ad..1144928ab75 100644 --- a/crates/iota-graphql-e2e-tests/tests/packages/structs.exp +++ b/crates/iota-graphql-e2e-tests/tests/packages/structs.exp @@ -154,19 +154,19 @@ Response: { "nodes": [ { "outputState": { - "address": "0x01df1e639fcb6895a9e429bc1451159e9555af99efa7a890d2aefaa9a64715bb", + "address": "0x1b2bdfde845714fd97810ccbf2f1395b476c4aee939e3f34d2f2e62e20804ed4", "asMovePackage": null } }, { "outputState": { - "address": "0x16a8e888439fb865e2ebb65d890e872be6717414f401f079b5741e67467ca41c", + "address": "0x5c1292f982e4f4162d6bda7f92177d35c6d0cfbb5b5317a91269d060fb7aa7af", "asMovePackage": null } }, { "outputState": { - "address": "0xfdc7773709c6f2c65d4cc9fbd7f8f2386ebc8262bb3e98f3bc3e530bfbedc0b0", + "address": "0x77ee5e2a86eab68c1f7a2bcd46ca4accf762a0b0579f348123896eda3c4799e4", "asMovePackage": { "module": { "struct": { @@ -224,25 +224,25 @@ Response: { "nodes": [ { "outputState": { - "address": "0x01df1e639fcb6895a9e429bc1451159e9555af99efa7a890d2aefaa9a64715bb", + "address": "0x1b2bdfde845714fd97810ccbf2f1395b476c4aee939e3f34d2f2e62e20804ed4", "asMovePackage": null } }, { "outputState": { - "address": "0x16a8e888439fb865e2ebb65d890e872be6717414f401f079b5741e67467ca41c", + "address": "0x5c1292f982e4f4162d6bda7f92177d35c6d0cfbb5b5317a91269d060fb7aa7af", "asMovePackage": null } }, { "outputState": { - "address": "0xdad85c173d1d2fb07344bcc64b496391646d774cf22e95c7285c7176ade2ce76", + "address": "0x68b559ac138602d697ab1e4122fbcf6a915990ab97383551b2d182118ac39274", "asMovePackage": { "module": { "s": { "module": { "package": { - "address": "0xfdc7773709c6f2c65d4cc9fbd7f8f2386ebc8262bb3e98f3bc3e530bfbedc0b0" + "address": "0x77ee5e2a86eab68c1f7a2bcd46ca4accf762a0b0579f348123896eda3c4799e4" } }, "name": "S", @@ -267,7 +267,7 @@ Response: { "t": { "module": { "package": { - "address": "0xdad85c173d1d2fb07344bcc64b496391646d774cf22e95c7285c7176ade2ce76" + "address": "0x68b559ac138602d697ab1e4122fbcf6a915990ab97383551b2d182118ac39274" } }, "name": "T", @@ -294,12 +294,12 @@ Response: { { "name": "s", "type": { - "repr": "0xfdc7773709c6f2c65d4cc9fbd7f8f2386ebc8262bb3e98f3bc3e530bfbedc0b0::m::S", + "repr": "0x77ee5e2a86eab68c1f7a2bcd46ca4accf762a0b0579f348123896eda3c4799e4::m::S", "signature": { "ref": null, "body": { "datatype": { - "package": "0xfdc7773709c6f2c65d4cc9fbd7f8f2386ebc8262bb3e98f3bc3e530bfbedc0b0", + "package": "0x77ee5e2a86eab68c1f7a2bcd46ca4accf762a0b0579f348123896eda3c4799e4", "module": "m", "type": "S", "typeParameters": [] @@ -328,7 +328,7 @@ Response: { { "name": "t", "type": { - "repr": "0xfdc7773709c6f2c65d4cc9fbd7f8f2386ebc8262bb3e98f3bc3e530bfbedc0b0::m::T<0xfdc7773709c6f2c65d4cc9fbd7f8f2386ebc8262bb3e98f3bc3e530bfbedc0b0::m::S>" + "repr": "0x77ee5e2a86eab68c1f7a2bcd46ca4accf762a0b0579f348123896eda3c4799e4::m::T<0x77ee5e2a86eab68c1f7a2bcd46ca4accf762a0b0579f348123896eda3c4799e4::m::S>" } } ] diff --git a/crates/iota-graphql-e2e-tests/tests/packages/types.exp b/crates/iota-graphql-e2e-tests/tests/packages/types.exp index f731c1ef6ed..a1f6e28517d 100644 --- a/crates/iota-graphql-e2e-tests/tests/packages/types.exp +++ b/crates/iota-graphql-e2e-tests/tests/packages/types.exp @@ -275,7 +275,7 @@ Response: { "data": null, "errors": [ { - "message": "Internal error occurred while processing request: Error calculating layout for 0x031f3c00b1e08a7663d48c96fa70684b022acc5fc423f9d1fbb60ac89af05e7e::m::S1: Type layout nesting exceeded limit of 128", + "message": "Internal error occurred while processing request: Error calculating layout for 0x317d8c42fd69e52da8a784d535b1cf53b9de0f7ec68ca200743d9a31e47f4771::m::S1: Type layout nesting exceeded limit of 128", "locations": [ { "line": 4, diff --git a/crates/iota-graphql-e2e-tests/tests/packages/versioning.exp b/crates/iota-graphql-e2e-tests/tests/packages/versioning.exp index 1621a244b2a..f3a09bea180 100644 --- a/crates/iota-graphql-e2e-tests/tests/packages/versioning.exp +++ b/crates/iota-graphql-e2e-tests/tests/packages/versioning.exp @@ -31,14 +31,14 @@ Response: { "packageVersions": { "nodes": [ { - "address": "0xd4313c43c3a911f170e773b3b7932bbcb1757046c826728fb48a95e0736bbafb", + "address": "0x93ced85142b761e5d9e14ce7c9bd93b00010355462230fc1df9ef0cd05b2d773", "version": 1 } ] } }, "firstPackage": { - "address": "0xd4313c43c3a911f170e773b3b7932bbcb1757046c826728fb48a95e0736bbafb", + "address": "0x93ced85142b761e5d9e14ce7c9bd93b00010355462230fc1df9ef0cd05b2d773", "version": 1, "module": { "functions": { @@ -52,7 +52,7 @@ Response: { "packageVersions": { "nodes": [ { - "address": "0xd4313c43c3a911f170e773b3b7932bbcb1757046c826728fb48a95e0736bbafb", + "address": "0x93ced85142b761e5d9e14ce7c9bd93b00010355462230fc1df9ef0cd05b2d773", "version": 1 } ] @@ -81,7 +81,7 @@ Response: { "version": 1 }, { - "address": "0xd4313c43c3a911f170e773b3b7932bbcb1757046c826728fb48a95e0736bbafb", + "address": "0x93ced85142b761e5d9e14ce7c9bd93b00010355462230fc1df9ef0cd05b2d773", "version": 1 } ] @@ -120,18 +120,18 @@ Response: { "packageVersions": { "nodes": [ { - "address": "0xd4313c43c3a911f170e773b3b7932bbcb1757046c826728fb48a95e0736bbafb", + "address": "0x93ced85142b761e5d9e14ce7c9bd93b00010355462230fc1df9ef0cd05b2d773", "version": 1 }, { - "address": "0xeaea5669c4477955a962870c0275f3b307883497f1691b181bcebde9dda76d08", + "address": "0xa1e60cf0ca1f2fc62f7eb917a89a71caae9980284aafa82ad418df82d6eb8f82", "version": 2 } ] } }, "firstPackage": { - "address": "0xd4313c43c3a911f170e773b3b7932bbcb1757046c826728fb48a95e0736bbafb", + "address": "0x93ced85142b761e5d9e14ce7c9bd93b00010355462230fc1df9ef0cd05b2d773", "version": 1, "module": { "functions": { @@ -145,11 +145,11 @@ Response: { "packageVersions": { "nodes": [ { - "address": "0xd4313c43c3a911f170e773b3b7932bbcb1757046c826728fb48a95e0736bbafb", + "address": "0x93ced85142b761e5d9e14ce7c9bd93b00010355462230fc1df9ef0cd05b2d773", "version": 1 }, { - "address": "0xeaea5669c4477955a962870c0275f3b307883497f1691b181bcebde9dda76d08", + "address": "0xa1e60cf0ca1f2fc62f7eb917a89a71caae9980284aafa82ad418df82d6eb8f82", "version": 2 } ] @@ -178,11 +178,11 @@ Response: { "version": 1 }, { - "address": "0xd4313c43c3a911f170e773b3b7932bbcb1757046c826728fb48a95e0736bbafb", + "address": "0x93ced85142b761e5d9e14ce7c9bd93b00010355462230fc1df9ef0cd05b2d773", "version": 1 }, { - "address": "0xeaea5669c4477955a962870c0275f3b307883497f1691b181bcebde9dda76d08", + "address": "0xa1e60cf0ca1f2fc62f7eb917a89a71caae9980284aafa82ad418df82d6eb8f82", "version": 2 } ] @@ -224,22 +224,22 @@ Response: { "packageVersions": { "nodes": [ { - "address": "0xd4313c43c3a911f170e773b3b7932bbcb1757046c826728fb48a95e0736bbafb", + "address": "0x93ced85142b761e5d9e14ce7c9bd93b00010355462230fc1df9ef0cd05b2d773", "version": 1 }, { - "address": "0xeaea5669c4477955a962870c0275f3b307883497f1691b181bcebde9dda76d08", + "address": "0xa1e60cf0ca1f2fc62f7eb917a89a71caae9980284aafa82ad418df82d6eb8f82", "version": 2 }, { - "address": "0x05384e77aa2501f0d36356d441b6071eaed2e43d1e02a357a9be6efb0c821c2d", + "address": "0x0b4ba6fb11093aee6043670f487eb02e0de56cf66fb1ccaf4c369bfba4346853", "version": 3 } ] } }, "firstPackage": { - "address": "0xd4313c43c3a911f170e773b3b7932bbcb1757046c826728fb48a95e0736bbafb", + "address": "0x93ced85142b761e5d9e14ce7c9bd93b00010355462230fc1df9ef0cd05b2d773", "version": 1, "module": { "functions": { @@ -253,15 +253,15 @@ Response: { "packageVersions": { "nodes": [ { - "address": "0xd4313c43c3a911f170e773b3b7932bbcb1757046c826728fb48a95e0736bbafb", + "address": "0x93ced85142b761e5d9e14ce7c9bd93b00010355462230fc1df9ef0cd05b2d773", "version": 1 }, { - "address": "0xeaea5669c4477955a962870c0275f3b307883497f1691b181bcebde9dda76d08", + "address": "0xa1e60cf0ca1f2fc62f7eb917a89a71caae9980284aafa82ad418df82d6eb8f82", "version": 2 }, { - "address": "0x05384e77aa2501f0d36356d441b6071eaed2e43d1e02a357a9be6efb0c821c2d", + "address": "0x0b4ba6fb11093aee6043670f487eb02e0de56cf66fb1ccaf4c369bfba4346853", "version": 3 } ] @@ -290,15 +290,15 @@ Response: { "version": 1 }, { - "address": "0xd4313c43c3a911f170e773b3b7932bbcb1757046c826728fb48a95e0736bbafb", + "address": "0x93ced85142b761e5d9e14ce7c9bd93b00010355462230fc1df9ef0cd05b2d773", "version": 1 }, { - "address": "0xeaea5669c4477955a962870c0275f3b307883497f1691b181bcebde9dda76d08", + "address": "0xa1e60cf0ca1f2fc62f7eb917a89a71caae9980284aafa82ad418df82d6eb8f82", "version": 2 }, { - "address": "0x05384e77aa2501f0d36356d441b6071eaed2e43d1e02a357a9be6efb0c821c2d", + "address": "0x0b4ba6fb11093aee6043670f487eb02e0de56cf66fb1ccaf4c369bfba4346853", "version": 3 } ] @@ -715,7 +715,7 @@ Response: { "after": { "nodes": [ { - "address": "0xeaea5669c4477955a962870c0275f3b307883497f1691b181bcebde9dda76d08", + "address": "0xa1e60cf0ca1f2fc62f7eb917a89a71caae9980284aafa82ad418df82d6eb8f82", "version": 2, "previousTransactionBlock": { "effects": { @@ -726,7 +726,7 @@ Response: { } }, { - "address": "0x05384e77aa2501f0d36356d441b6071eaed2e43d1e02a357a9be6efb0c821c2d", + "address": "0x0b4ba6fb11093aee6043670f487eb02e0de56cf66fb1ccaf4c369bfba4346853", "version": 3, "previousTransactionBlock": { "effects": { @@ -741,7 +741,7 @@ Response: { "between": { "nodes": [ { - "address": "0xeaea5669c4477955a962870c0275f3b307883497f1691b181bcebde9dda76d08", + "address": "0xa1e60cf0ca1f2fc62f7eb917a89a71caae9980284aafa82ad418df82d6eb8f82", "version": 2, "previousTransactionBlock": { "effects": { @@ -763,15 +763,15 @@ Response: { "packageVersions": { "nodes": [ { - "address": "0xd4313c43c3a911f170e773b3b7932bbcb1757046c826728fb48a95e0736bbafb", + "address": "0x93ced85142b761e5d9e14ce7c9bd93b00010355462230fc1df9ef0cd05b2d773", "version": 1 }, { - "address": "0xeaea5669c4477955a962870c0275f3b307883497f1691b181bcebde9dda76d08", + "address": "0xa1e60cf0ca1f2fc62f7eb917a89a71caae9980284aafa82ad418df82d6eb8f82", "version": 2 }, { - "address": "0x05384e77aa2501f0d36356d441b6071eaed2e43d1e02a357a9be6efb0c821c2d", + "address": "0x0b4ba6fb11093aee6043670f487eb02e0de56cf66fb1ccaf4c369bfba4346853", "version": 3 } ] @@ -779,11 +779,11 @@ Response: { "after": { "nodes": [ { - "address": "0xeaea5669c4477955a962870c0275f3b307883497f1691b181bcebde9dda76d08", + "address": "0xa1e60cf0ca1f2fc62f7eb917a89a71caae9980284aafa82ad418df82d6eb8f82", "version": 2 }, { - "address": "0x05384e77aa2501f0d36356d441b6071eaed2e43d1e02a357a9be6efb0c821c2d", + "address": "0x0b4ba6fb11093aee6043670f487eb02e0de56cf66fb1ccaf4c369bfba4346853", "version": 3 } ] @@ -791,11 +791,11 @@ Response: { "before": { "nodes": [ { - "address": "0xd4313c43c3a911f170e773b3b7932bbcb1757046c826728fb48a95e0736bbafb", + "address": "0x93ced85142b761e5d9e14ce7c9bd93b00010355462230fc1df9ef0cd05b2d773", "version": 1 }, { - "address": "0xeaea5669c4477955a962870c0275f3b307883497f1691b181bcebde9dda76d08", + "address": "0xa1e60cf0ca1f2fc62f7eb917a89a71caae9980284aafa82ad418df82d6eb8f82", "version": 2 } ] @@ -803,7 +803,7 @@ Response: { "between": { "nodes": [ { - "address": "0xeaea5669c4477955a962870c0275f3b307883497f1691b181bcebde9dda76d08", + "address": "0xa1e60cf0ca1f2fc62f7eb917a89a71caae9980284aafa82ad418df82d6eb8f82", "version": 2 } ] diff --git a/crates/iota-graphql-e2e-tests/tests/transaction_block_effects/balance_changes.exp b/crates/iota-graphql-e2e-tests/tests/transaction_block_effects/balance_changes.exp index 8a57c332a50..58869ad01d0 100644 --- a/crates/iota-graphql-e2e-tests/tests/transaction_block_effects/balance_changes.exp +++ b/crates/iota-graphql-e2e-tests/tests/transaction_block_effects/balance_changes.exp @@ -48,13 +48,13 @@ Response: { "edges": [ { "node": { - "amount": "5000" + "amount": "4000" }, "cursor": "eyJpIjowLCJjIjoyfQ" }, { "node": { - "amount": "2000" + "amount": "1000" }, "cursor": "eyJpIjoxLCJjIjoyfQ" }, @@ -66,19 +66,19 @@ Response: { }, { "node": { - "amount": "1000" + "amount": "2000" }, "cursor": "eyJpIjozLCJjIjoyfQ" }, { "node": { - "amount": "3000" + "amount": "5000" }, "cursor": "eyJpIjo0LCJjIjoyfQ" }, { "node": { - "amount": "4000" + "amount": "3000" }, "cursor": "eyJpIjo1LCJjIjoyfQ" } @@ -111,13 +111,13 @@ Response: { "edges": [ { "node": { - "amount": "1000" + "amount": "2000" }, "cursor": "eyJpIjozLCJjIjoxfQ" }, { "node": { - "amount": "3000" + "amount": "5000" }, "cursor": "eyJpIjo0LCJjIjoxfQ" } @@ -150,13 +150,13 @@ Response: { "edges": [ { "node": { - "amount": "5000" + "amount": "4000" }, "cursor": "eyJpIjowLCJjIjoxfQ" }, { "node": { - "amount": "2000" + "amount": "1000" }, "cursor": "eyJpIjoxLCJjIjoxfQ" }, diff --git a/crates/iota-graphql-e2e-tests/tests/transaction_block_effects/dependencies.exp b/crates/iota-graphql-e2e-tests/tests/transaction_block_effects/dependencies.exp index 0bf1900be38..8498f8bf4d7 100644 --- a/crates/iota-graphql-e2e-tests/tests/transaction_block_effects/dependencies.exp +++ b/crates/iota-graphql-e2e-tests/tests/transaction_block_effects/dependencies.exp @@ -65,7 +65,7 @@ Response: { "transactionBlocks": { "nodes": [ { - "digest": "42fGuDs8aQxGjEqKymwG1KQWaRyd7xXxyepLyd8MKDLu", + "digest": "9pCyhXkr2tCkQh57rhbAEgELoLvUiiSN9M8gPqnn724p", "effects": { "dependencies": { "pageInfo": { @@ -78,26 +78,15 @@ Response: { { "cursor": "eyJpIjowLCJjIjoxfQ", "node": { - "digest": "4zoVEmZwsi62buCayUU8Skgc5jNx3nnQvUtQCncotRXj", + "digest": "C3fuzD6g6RtyaXcFfGepQcgNy5a2rxpLcepvvGbYKVVA", "kind": { "__typename": "ProgrammableTransactionBlock", "transactions": { "nodes": [ + {}, { - "module": "M1", - "functionName": "sum" - }, - { - "module": "M1", - "functionName": "sum" - }, - { - "module": "M1", - "functionName": "sum" - }, - { - "module": "M1", - "functionName": "create" + "module": "package", + "functionName": "make_immutable" } ] } @@ -107,15 +96,26 @@ Response: { { "cursor": "eyJpIjoxLCJjIjoxfQ", "node": { - "digest": "Hv4oG9EB5nPxKgyLCyAonFFUa97mxLnUXVapMBu2nH43", + "digest": "FpvfXRTXL67N8gJukHxVLVBJ45ao2ZCgyNLbMZQgvWeh", "kind": { "__typename": "ProgrammableTransactionBlock", "transactions": { "nodes": [ - {}, { - "module": "package", - "functionName": "make_immutable" + "module": "M1", + "functionName": "sum" + }, + { + "module": "M1", + "functionName": "sum" + }, + { + "module": "M1", + "functionName": "sum" + }, + { + "module": "M1", + "functionName": "create" } ] } @@ -138,7 +138,7 @@ Response: { "transactionBlocks": { "nodes": [ { - "digest": "42fGuDs8aQxGjEqKymwG1KQWaRyd7xXxyepLyd8MKDLu", + "digest": "9pCyhXkr2tCkQh57rhbAEgELoLvUiiSN9M8gPqnn724p", "effects": { "dependencies": { "pageInfo": { @@ -151,15 +151,26 @@ Response: { { "cursor": "eyJpIjoxLCJjIjoxfQ", "node": { - "digest": "Hv4oG9EB5nPxKgyLCyAonFFUa97mxLnUXVapMBu2nH43", + "digest": "FpvfXRTXL67N8gJukHxVLVBJ45ao2ZCgyNLbMZQgvWeh", "kind": { "__typename": "ProgrammableTransactionBlock", "transactions": { "nodes": [ - {}, { - "module": "package", - "functionName": "make_immutable" + "module": "M1", + "functionName": "sum" + }, + { + "module": "M1", + "functionName": "sum" + }, + { + "module": "M1", + "functionName": "sum" + }, + { + "module": "M1", + "functionName": "create" } ] } diff --git a/crates/iota-graphql-e2e-tests/tests/transactions/at_checkpoint.exp b/crates/iota-graphql-e2e-tests/tests/transactions/at_checkpoint.exp index 9038014fdc2..88d6cb566fd 100644 --- a/crates/iota-graphql-e2e-tests/tests/transactions/at_checkpoint.exp +++ b/crates/iota-graphql-e2e-tests/tests/transactions/at_checkpoint.exp @@ -30,7 +30,7 @@ Response: { "c0": { "nodes": [ { - "digest": "GcUyosXyBY31652hSgsU5Gde7jzPyTQimDfM2GznB1S2", + "digest": "CNw9XYFVwjaghvZWf98a5FmYs5MVtnqCSrFwpUtK6Gm", "kind": { "__typename": "GenesisTransaction" } @@ -46,7 +46,7 @@ Response: { } }, { - "digest": "9BxxY2aKepD3ktJ3QEsP1vjAJkjtwQMw5p6csFUB17Pf", + "digest": "BVMk8VzSAJQwwW57SCSRdSBFxHPjbsLLzRw4ynJj2gLF", "kind": { "__typename": "ProgrammableTransactionBlock" } @@ -87,7 +87,7 @@ Response: { "transactionBlocks": { "nodes": [ { - "digest": "GcUyosXyBY31652hSgsU5Gde7jzPyTQimDfM2GznB1S2", + "digest": "CNw9XYFVwjaghvZWf98a5FmYs5MVtnqCSrFwpUtK6Gm", "kind": { "__typename": "GenesisTransaction" } @@ -105,7 +105,7 @@ Response: { } }, { - "digest": "9BxxY2aKepD3ktJ3QEsP1vjAJkjtwQMw5p6csFUB17Pf", + "digest": "BVMk8VzSAJQwwW57SCSRdSBFxHPjbsLLzRw4ynJj2gLF", "kind": { "__typename": "ProgrammableTransactionBlock" } @@ -154,7 +154,7 @@ Response: { "transactionBlocks": { "nodes": [ { - "digest": "GcUyosXyBY31652hSgsU5Gde7jzPyTQimDfM2GznB1S2", + "digest": "CNw9XYFVwjaghvZWf98a5FmYs5MVtnqCSrFwpUtK6Gm", "kind": { "__typename": "GenesisTransaction" } @@ -172,7 +172,7 @@ Response: { } }, { - "digest": "9BxxY2aKepD3ktJ3QEsP1vjAJkjtwQMw5p6csFUB17Pf", + "digest": "BVMk8VzSAJQwwW57SCSRdSBFxHPjbsLLzRw4ynJj2gLF", "kind": { "__typename": "ProgrammableTransactionBlock" } diff --git a/crates/iota-graphql-e2e-tests/tests/transactions/errors.exp b/crates/iota-graphql-e2e-tests/tests/transactions/errors.exp index 73b69dd5520..c9a9b9ab924 100644 --- a/crates/iota-graphql-e2e-tests/tests/transactions/errors.exp +++ b/crates/iota-graphql-e2e-tests/tests/transactions/errors.exp @@ -25,7 +25,7 @@ Response: { { "effects": { "status": "FAILURE", - "errors": "Error in 1st command, from '0xec93b0e3c417e18e054f00f0cc4c66b8a78539a949ca5b306620b7f8aaf5913d::m::boom' (instruction 1), abort code: 42" + "errors": "Error in 1st command, from '0xba8d4a8da99b1a4d634efec621be8572f2ef2ef03409d2b673e58c7b9c7691de::m::boom' (instruction 1), abort code: 42" } } ] @@ -54,7 +54,7 @@ Response: { { "effects": { "status": "FAILURE", - "errors": "Error in 3rd command, from '0xec93b0e3c417e18e054f00f0cc4c66b8a78539a949ca5b306620b7f8aaf5913d::m::boom' (instruction 1), abort code: 42" + "errors": "Error in 3rd command, from '0xba8d4a8da99b1a4d634efec621be8572f2ef2ef03409d2b673e58c7b9c7691de::m::boom' (instruction 1), abort code: 42" } } ] diff --git a/crates/iota-graphql-e2e-tests/tests/transactions/filters/kind.exp b/crates/iota-graphql-e2e-tests/tests/transactions/filters/kind.exp index f0919b2d060..272ac52ad2c 100644 --- a/crates/iota-graphql-e2e-tests/tests/transactions/filters/kind.exp +++ b/crates/iota-graphql-e2e-tests/tests/transactions/filters/kind.exp @@ -60,7 +60,7 @@ Response: { }, "nodes": [ { - "digest": "BrmwoxKGkndWUriBkmajng7GuWDDDJwgfu9wwGuN9zev", + "digest": "E3fHXmQFb8QHghYBJse4k4F2HLEZTACD2XMGw7UHec1p", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -68,7 +68,7 @@ Response: { } }, { - "digest": "5ksUtqcbsG5tM57GXnAWqPopAYzgnpGnCnRFSTw4Awb3", + "digest": "D5fnktTARqHzLNYKKpFN7K3U1VbEGNDjWo5vDy7NT14p", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -76,7 +76,7 @@ Response: { } }, { - "digest": "AN5sVYJHUTVTYnFYgwkyukLMXSUscg7YKax42d9135FX", + "digest": "7yrviMHuiaKBmDxqyb7Byzh4Tv735x4GDRA1i5NtcjpN", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -84,7 +84,7 @@ Response: { } }, { - "digest": "DFeFptJ3Tc3sAmBYdrsbDZnEJ8zDnvp4byqzaXzewaG4", + "digest": "D9nqoByPvocsTQonrtydYMZrUSH75qB7ro2k3oGP4Huo", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -92,7 +92,7 @@ Response: { } }, { - "digest": "6P1wyYsPmDahzvWjTqtFSTqASLqiVQx4YB2e3gN7Vq7V", + "digest": "DsgWBPabTgUShBimgoTSF1s41NGpMr4r5YTHps7Hdhv5", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -117,7 +117,7 @@ Response: { }, "nodes": [ { - "digest": "BrmwoxKGkndWUriBkmajng7GuWDDDJwgfu9wwGuN9zev", + "digest": "E3fHXmQFb8QHghYBJse4k4F2HLEZTACD2XMGw7UHec1p", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -142,7 +142,7 @@ Response: { }, "nodes": [ { - "digest": "5ksUtqcbsG5tM57GXnAWqPopAYzgnpGnCnRFSTw4Awb3", + "digest": "D5fnktTARqHzLNYKKpFN7K3U1VbEGNDjWo5vDy7NT14p", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -167,7 +167,7 @@ Response: { }, "nodes": [ { - "digest": "AN5sVYJHUTVTYnFYgwkyukLMXSUscg7YKax42d9135FX", + "digest": "7yrviMHuiaKBmDxqyb7Byzh4Tv735x4GDRA1i5NtcjpN", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -192,7 +192,7 @@ Response: { }, "nodes": [ { - "digest": "DFeFptJ3Tc3sAmBYdrsbDZnEJ8zDnvp4byqzaXzewaG4", + "digest": "D9nqoByPvocsTQonrtydYMZrUSH75qB7ro2k3oGP4Huo", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -217,7 +217,7 @@ Response: { }, "nodes": [ { - "digest": "6P1wyYsPmDahzvWjTqtFSTqASLqiVQx4YB2e3gN7Vq7V", + "digest": "DsgWBPabTgUShBimgoTSF1s41NGpMr4r5YTHps7Hdhv5", "effects": { "checkpoint": { "sequenceNumber": 2 diff --git a/crates/iota-graphql-e2e-tests/tests/transactions/programmable.exp b/crates/iota-graphql-e2e-tests/tests/transactions/programmable.exp index 388358ae4f3..7673cae8f34 100644 --- a/crates/iota-graphql-e2e-tests/tests/transactions/programmable.exp +++ b/crates/iota-graphql-e2e-tests/tests/transactions/programmable.exp @@ -20,12 +20,12 @@ Response: { "transactionBlocks": { "nodes": [ { - "digest": "7yu83zzohW1XpMxHAwrUrivcfdqmdh2KCKvZ37v5iPBg", + "digest": "EEvFNycnDYWz8o7ekDmsGLj3BHnXndRaMguMbRA1x1Qb", "sender": { "address": "0x8cca4e1ce0ba5904cea61df9242da2f7d29e3ef328fb7ec07c086b3bf47ca61a" }, "signatures": [ - "AKoXg/6D5YGXLPA9oIT9KLV3H/24fNJoZt9W7fPVKt4SUEYbX8S8DHZBmA5SkAXSbl2t9v7jBkKaUpy0pa8luwx/UUY663bYjcm3XmNyULIgxJz1t5Z9vxfB+fp8WUoJKA==" + "ANWEFJzs360MMlnYx5pPnDzQ1CM1NGfyatQVhLLCQ7QIAK781x1TUi3558YCbamgg/hVy6RYmEnDX40u0PsxJQB/UUY663bYjcm3XmNyULIgxJz1t5Z9vxfB+fp8WUoJKA==" ], "gasInput": { "gasSponsor": { @@ -34,7 +34,7 @@ Response: { "gasPayment": { "nodes": [ { - "address": "0x16a8e888439fb865e2ebb65d890e872be6717414f401f079b5741e67467ca41c" + "address": "0x5c1292f982e4f4162d6bda7f92177d35c6d0cfbb5b5317a91269d060fb7aa7af" } ] }, @@ -96,7 +96,7 @@ Response: { "dependencies": { "nodes": [ { - "digest": "GcUyosXyBY31652hSgsU5Gde7jzPyTQimDfM2GznB1S2" + "digest": "CNw9XYFVwjaghvZWf98a5FmYs5MVtnqCSrFwpUtK6Gm" } ] }, @@ -116,37 +116,37 @@ Response: { "objectChanges": { "nodes": [ { - "address": "0x0846efff08221f9685365d064287d49054327432c48741661d46f494b2f84c8d", - "idCreated": true, + "address": "0x5c1292f982e4f4162d6bda7f92177d35c6d0cfbb5b5317a91269d060fb7aa7af", + "idCreated": false, "idDeleted": false, "outputState": { - "address": "0x0846efff08221f9685365d064287d49054327432c48741661d46f494b2f84c8d", - "digest": "3kdnX61T9paJQeedhS8QYKCAdAx2ja5mWbDMtMzEzRdC" + "address": "0x5c1292f982e4f4162d6bda7f92177d35c6d0cfbb5b5317a91269d060fb7aa7af", + "digest": "5KGPZwdxn3xtGaHjyTW2Pp2jRsfdPL75MWxWFgNUQ3S7" } }, { - "address": "0x16a8e888439fb865e2ebb65d890e872be6717414f401f079b5741e67467ca41c", - "idCreated": false, + "address": "0xb13cb331988d6067f70d5a1c715be0203ff1cec6983c481196f0225e9da9bda1", + "idCreated": true, "idDeleted": false, "outputState": { - "address": "0x16a8e888439fb865e2ebb65d890e872be6717414f401f079b5741e67467ca41c", - "digest": "2b1szGUEp7X4W6G43J3gs6qUvyofEKG6Xqto7qJdtvQQ" + "address": "0xb13cb331988d6067f70d5a1c715be0203ff1cec6983c481196f0225e9da9bda1", + "digest": "AWnh5JWaCiBBLzYrHDydq7muhGxyvCrx8qXAVwAiGuFW" } }, { - "address": "0x4727e7a070d440299c8918a5b0361df08474a087d088351f36158e2b5667d827", + "address": "0xeafbcd896fa977e961d0ab34f33a0f8ef4d8f249b244895d3f2c17d8d28352a5", "idCreated": true, "idDeleted": false, "outputState": { - "address": "0x4727e7a070d440299c8918a5b0361df08474a087d088351f36158e2b5667d827", - "digest": "CoaEaKR1McozywApryxJWWxEYuncs5cuiFtUsve8qu7d" + "address": "0xeafbcd896fa977e961d0ab34f33a0f8ef4d8f249b244895d3f2c17d8d28352a5", + "digest": "9L69ChGvUnBAkhxeYJrfrBKTvh6KYxzu4MSvLDxwHtJB" } } ] }, "gasEffects": { "gasObject": { - "address": "0x16a8e888439fb865e2ebb65d890e872be6717414f401f079b5741e67467ca41c" + "address": "0x5c1292f982e4f4162d6bda7f92177d35c6d0cfbb5b5317a91269d060fb7aa7af" }, "gasSummary": { "computationCost": "1000000", @@ -163,7 +163,7 @@ Response: { "sequenceNumber": 1 }, "transactionBlock": { - "digest": "7yu83zzohW1XpMxHAwrUrivcfdqmdh2KCKvZ37v5iPBg" + "digest": "EEvFNycnDYWz8o7ekDmsGLj3BHnXndRaMguMbRA1x1Qb" } }, "expiration": null @@ -190,12 +190,12 @@ Response: { "transactionBlocks": { "nodes": [ { - "digest": "9cxJZcyPgXjMPmoTBxM7PQ1Z1LEFSPXdBFV5UNYcBBsr", + "digest": "9XhEpQ8YEnaHJiYBmTdVaHH1kHBCuv5Nn9gH6MNQhZQW", "sender": { "address": "0x8cca4e1ce0ba5904cea61df9242da2f7d29e3ef328fb7ec07c086b3bf47ca61a" }, "signatures": [ - "ACvyxn5vTOoJ2R/Cn2W8tvENjipIcrUTfNCCTlM3BgPXQxtV7Bfo4E2fmEUHGhBcfvyP3AHVi9HOUPJGmJuW5QN/UUY663bYjcm3XmNyULIgxJz1t5Z9vxfB+fp8WUoJKA==" + "AKWRFhFX5MsJsB24J2geLc5QYCeBO8AwcMdKyb48mSPKaQKMbsEZ2Y9xTLmgVPHU4S7/SlEzrSviJUXPHTNBdwZ/UUY663bYjcm3XmNyULIgxJz1t5Z9vxfB+fp8WUoJKA==" ], "gasInput": { "gasSponsor": { @@ -204,7 +204,7 @@ Response: { "gasPayment": { "nodes": [ { - "address": "0x16a8e888439fb865e2ebb65d890e872be6717414f401f079b5741e67467ca41c" + "address": "0x5c1292f982e4f4162d6bda7f92177d35c6d0cfbb5b5317a91269d060fb7aa7af" } ] }, @@ -219,21 +219,21 @@ Response: { "cursor": "eyJpIjowLCJjIjoyfQ", "node": { "__typename": "OwnedOrImmutable", - "address": "0x0846efff08221f9685365d064287d49054327432c48741661d46f494b2f84c8d", + "address": "0xeafbcd896fa977e961d0ab34f33a0f8ef4d8f249b244895d3f2c17d8d28352a5", "version": 2, - "digest": "3kdnX61T9paJQeedhS8QYKCAdAx2ja5mWbDMtMzEzRdC", + "digest": "9L69ChGvUnBAkhxeYJrfrBKTvh6KYxzu4MSvLDxwHtJB", "object": { - "address": "0x0846efff08221f9685365d064287d49054327432c48741661d46f494b2f84c8d", + "address": "0xeafbcd896fa977e961d0ab34f33a0f8ef4d8f249b244895d3f2c17d8d28352a5", "version": 2, - "digest": "3kdnX61T9paJQeedhS8QYKCAdAx2ja5mWbDMtMzEzRdC", + "digest": "9L69ChGvUnBAkhxeYJrfrBKTvh6KYxzu4MSvLDxwHtJB", "asMoveObject": { "contents": { "type": { "repr": "0x0000000000000000000000000000000000000000000000000000000000000002::package::UpgradeCap" }, "json": { - "id": "0x0846efff08221f9685365d064287d49054327432c48741661d46f494b2f84c8d", - "package": "0x4727e7a070d440299c8918a5b0361df08474a087d088351f36158e2b5667d827", + "id": "0xeafbcd896fa977e961d0ab34f33a0f8ef4d8f249b244895d3f2c17d8d28352a5", + "package": "0xb13cb331988d6067f70d5a1c715be0203ff1cec6983c481196f0225e9da9bda1", "version": "1", "policy": 0 } @@ -315,7 +315,7 @@ Response: { "0x0000000000000000000000000000000000000000000000000000000000000001", "0x0000000000000000000000000000000000000000000000000000000000000002" ], - "currentPackage": "0x4727e7a070d440299c8918a5b0361df08474a087d088351f36158e2b5667d827", + "currentPackage": "0xb13cb331988d6067f70d5a1c715be0203ff1cec6983c481196f0225e9da9bda1", "upgradeTicket": { "__typename": "Result", "cmd": 0, @@ -367,10 +367,10 @@ Response: { "dependencies": { "nodes": [ { - "digest": "7yu83zzohW1XpMxHAwrUrivcfdqmdh2KCKvZ37v5iPBg" + "digest": "CNw9XYFVwjaghvZWf98a5FmYs5MVtnqCSrFwpUtK6Gm" }, { - "digest": "GcUyosXyBY31652hSgsU5Gde7jzPyTQimDfM2GznB1S2" + "digest": "EEvFNycnDYWz8o7ekDmsGLj3BHnXndRaMguMbRA1x1Qb" } ] }, @@ -390,37 +390,37 @@ Response: { "objectChanges": { "nodes": [ { - "address": "0x0846efff08221f9685365d064287d49054327432c48741661d46f494b2f84c8d", + "address": "0x5c1292f982e4f4162d6bda7f92177d35c6d0cfbb5b5317a91269d060fb7aa7af", "idCreated": false, "idDeleted": false, "outputState": { - "address": "0x0846efff08221f9685365d064287d49054327432c48741661d46f494b2f84c8d", - "digest": "5rqHkqTAvB4gGrpdwKB3X7yx42fQPmXkjQX6HquzE4YQ" + "address": "0x5c1292f982e4f4162d6bda7f92177d35c6d0cfbb5b5317a91269d060fb7aa7af", + "digest": "GZ919iJ6Gwv6XsyWzTh9uHbwWTHz7XeJ2uMfYHe5D5HP" } }, { - "address": "0x16a8e888439fb865e2ebb65d890e872be6717414f401f079b5741e67467ca41c", - "idCreated": false, + "address": "0xd92ae8b03f6ac4daf76d876938fcc2a593e7ff406dad1ee0e1a5b95f6cb65434", + "idCreated": true, "idDeleted": false, "outputState": { - "address": "0x16a8e888439fb865e2ebb65d890e872be6717414f401f079b5741e67467ca41c", - "digest": "3hPsFkPRBXXQZa5B6yfaMC1cB5rKq79NPwWHJJDfzs5G" + "address": "0xd92ae8b03f6ac4daf76d876938fcc2a593e7ff406dad1ee0e1a5b95f6cb65434", + "digest": "5vGPcn2fi3JKnAcU4SY3CcaSRQn3ydaHKPJd37T8vE8Q" } }, { - "address": "0x636fec2071b067cd47d6388d380d029b6bbfe255e75ebdec9106a60f26d90560", - "idCreated": true, + "address": "0xeafbcd896fa977e961d0ab34f33a0f8ef4d8f249b244895d3f2c17d8d28352a5", + "idCreated": false, "idDeleted": false, "outputState": { - "address": "0x636fec2071b067cd47d6388d380d029b6bbfe255e75ebdec9106a60f26d90560", - "digest": "Bn3mxU9z7FrdUHXYFsm9f26wftdPkN29JswS5SGKpT6Y" + "address": "0xeafbcd896fa977e961d0ab34f33a0f8ef4d8f249b244895d3f2c17d8d28352a5", + "digest": "F8bm8Wy2a1cVmrksJ8pTi2puh1xQeu7JWPeqjVQ3CkvK" } } ] }, "gasEffects": { "gasObject": { - "address": "0x16a8e888439fb865e2ebb65d890e872be6717414f401f079b5741e67467ca41c" + "address": "0x5c1292f982e4f4162d6bda7f92177d35c6d0cfbb5b5317a91269d060fb7aa7af" }, "gasSummary": { "computationCost": "1000000", @@ -437,7 +437,7 @@ Response: { "sequenceNumber": 2 }, "transactionBlock": { - "digest": "9cxJZcyPgXjMPmoTBxM7PQ1Z1LEFSPXdBFV5UNYcBBsr" + "digest": "9XhEpQ8YEnaHJiYBmTdVaHH1kHBCuv5Nn9gH6MNQhZQW" } }, "expiration": null @@ -482,12 +482,12 @@ Response: { "transactionBlocks": { "nodes": [ { - "digest": "JDtQReNP9NNFzaR91VpSitkB1cw11g41n4ieVCcLW2Ke", + "digest": "7ScQwMi7B9V5EgXAZMJpmTWztT4fZJN7BFWStEkW69Cr", "sender": { "address": "0x8cca4e1ce0ba5904cea61df9242da2f7d29e3ef328fb7ec07c086b3bf47ca61a" }, "signatures": [ - "ABcl1+dP9M/d04GQDpNCcmgfAojVDelh7UML/+nWlF9vVzM/9Zgu3tAX95EhDsMC/nlkwzg/Xd+kGKZtyVUZIw9/UUY663bYjcm3XmNyULIgxJz1t5Z9vxfB+fp8WUoJKA==" + "ACZTcpYTyN06yg++IS64MJ/VfRGE1mRSQRa43uCpXP+U6c0mgtyl/dvFVeeUOPMd5XroJVJhzNs/ZBxfPdS+6AZ/UUY663bYjcm3XmNyULIgxJz1t5Z9vxfB+fp8WUoJKA==" ], "gasInput": { "gasSponsor": { @@ -496,7 +496,7 @@ Response: { "gasPayment": { "nodes": [ { - "address": "0x16a8e888439fb865e2ebb65d890e872be6717414f401f079b5741e67467ca41c" + "address": "0x5c1292f982e4f4162d6bda7f92177d35c6d0cfbb5b5317a91269d060fb7aa7af" } ] }, @@ -591,7 +591,7 @@ Response: { "cursor": "eyJpIjozLCJjIjozfQ", "node": { "__typename": "MoveCallTransaction", - "package": "0x636fec2071b067cd47d6388d380d029b6bbfe255e75ebdec9106a60f26d90560", + "package": "0xd92ae8b03f6ac4daf76d876938fcc2a593e7ff406dad1ee0e1a5b95f6cb65434", "module": "m", "functionName": "new", "typeArguments": [], @@ -615,7 +615,7 @@ Response: { ], "return": [ { - "repr": "0x4727e7a070d440299c8918a5b0361df08474a087d088351f36158e2b5667d827::m::Foo" + "repr": "0xb13cb331988d6067f70d5a1c715be0203ff1cec6983c481196f0225e9da9bda1::m::Foo" } ] } @@ -642,7 +642,7 @@ Response: { "cursor": "eyJpIjo1LCJjIjozfQ", "node": { "__typename": "MoveCallTransaction", - "package": "0x636fec2071b067cd47d6388d380d029b6bbfe255e75ebdec9106a60f26d90560", + "package": "0xd92ae8b03f6ac4daf76d876938fcc2a593e7ff406dad1ee0e1a5b95f6cb65434", "module": "m", "functionName": "new", "typeArguments": [], @@ -666,7 +666,7 @@ Response: { ], "return": [ { - "repr": "0x4727e7a070d440299c8918a5b0361df08474a087d088351f36158e2b5667d827::m::Foo" + "repr": "0xb13cb331988d6067f70d5a1c715be0203ff1cec6983c481196f0225e9da9bda1::m::Foo" } ] } @@ -676,7 +676,7 @@ Response: { "cursor": "eyJpIjo2LCJjIjozfQ", "node": { "__typename": "MoveCallTransaction", - "package": "0x636fec2071b067cd47d6388d380d029b6bbfe255e75ebdec9106a60f26d90560", + "package": "0xd92ae8b03f6ac4daf76d876938fcc2a593e7ff406dad1ee0e1a5b95f6cb65434", "module": "m", "functionName": "burn", "typeArguments": [], @@ -692,7 +692,7 @@ Response: { "typeParameters": [], "parameters": [ { - "repr": "0x4727e7a070d440299c8918a5b0361df08474a087d088351f36158e2b5667d827::m::Foo" + "repr": "0xb13cb331988d6067f70d5a1c715be0203ff1cec6983c481196f0225e9da9bda1::m::Foo" } ], "return": [] @@ -744,10 +744,10 @@ Response: { "dependencies": { "nodes": [ { - "digest": "9cxJZcyPgXjMPmoTBxM7PQ1Z1LEFSPXdBFV5UNYcBBsr" + "digest": "5yUiJzLrCmBipGvjVBovnEGgXF29jwam3JYhnYtkPEsy" }, { - "digest": "Cs9826UoCWKf1hNiL3AvZLUNEdvbjq7koKgSCW3JZFjD" + "digest": "9XhEpQ8YEnaHJiYBmTdVaHH1kHBCuv5Nn9gH6MNQhZQW" } ] }, @@ -767,19 +767,19 @@ Response: { "objectChanges": { "nodes": [ { - "address": "0x16a8e888439fb865e2ebb65d890e872be6717414f401f079b5741e67467ca41c", + "address": "0x5c1292f982e4f4162d6bda7f92177d35c6d0cfbb5b5317a91269d060fb7aa7af", "idCreated": false, "idDeleted": false, "outputState": { - "address": "0x16a8e888439fb865e2ebb65d890e872be6717414f401f079b5741e67467ca41c", - "digest": "Axs9o9g6zRLWTk8y4h6yFgZViTPzF4RXaGNpnkce8gxU", + "address": "0x5c1292f982e4f4162d6bda7f92177d35c6d0cfbb5b5317a91269d060fb7aa7af", + "digest": "HFmgTgnCkfsPBjztNYZfFrb1RMGGoq14RQH2zzd17Y8D", "asMoveObject": { "contents": { "type": { "repr": "0x0000000000000000000000000000000000000000000000000000000000000002::coin::Coin<0x0000000000000000000000000000000000000000000000000000000000000002::iota::IOTA>" }, "json": { - "id": "0x16a8e888439fb865e2ebb65d890e872be6717414f401f079b5741e67467ca41c", + "id": "0x5c1292f982e4f4162d6bda7f92177d35c6d0cfbb5b5317a91269d060fb7aa7af", "balance": { "value": "299999982082400" } @@ -789,45 +789,45 @@ Response: { } }, { - "address": "0x3ae6702801c6902eb3bdc76e3f254e336a50f37903c9537fb08ebdc66af45af4", + "address": "0xb076b3d51ddcb3c3bfa23c0d3ee2f1cca08e77c2546d2057c82275dbbc8dffff", "idCreated": true, "idDeleted": false, "outputState": { - "address": "0x3ae6702801c6902eb3bdc76e3f254e336a50f37903c9537fb08ebdc66af45af4", - "digest": "CuFbeNaTANhD4P9um1KeZq3N6yLAE9YfEqph3x7naeVy", + "address": "0xb076b3d51ddcb3c3bfa23c0d3ee2f1cca08e77c2546d2057c82275dbbc8dffff", + "digest": "BkvCYiVf16JB68DSUSD2Q9WnxAxZKzVv1akmhS2S7rMd", "asMoveObject": { "contents": { "type": { - "repr": "0x4727e7a070d440299c8918a5b0361df08474a087d088351f36158e2b5667d827::m::Foo" + "repr": "0x0000000000000000000000000000000000000000000000000000000000000002::coin::Coin<0x0000000000000000000000000000000000000000000000000000000000000002::iota::IOTA>" }, "json": { - "id": "0x3ae6702801c6902eb3bdc76e3f254e336a50f37903c9537fb08ebdc66af45af4", - "xs": [ - "42", - "43" - ] + "id": "0xb076b3d51ddcb3c3bfa23c0d3ee2f1cca08e77c2546d2057c82275dbbc8dffff", + "balance": { + "value": "2000" + } } } } } }, { - "address": "0x74b6c16a640092f327aa742a3f444c8a9c0e99e048736735e99e0639202f07da", + "address": "0xfc0517b5eab059e852955967e0fd4fd317548abc3c0aaed13a339ef1d883748f", "idCreated": true, "idDeleted": false, "outputState": { - "address": "0x74b6c16a640092f327aa742a3f444c8a9c0e99e048736735e99e0639202f07da", - "digest": "H7p7DsvGqkan27ADQsooKx3v8MZwgDTS5LDBnV1S34pw", + "address": "0xfc0517b5eab059e852955967e0fd4fd317548abc3c0aaed13a339ef1d883748f", + "digest": "4yQEGwrULKp2tW4My8idvVNE9ZjPwbqGXB78LZZzzmLK", "asMoveObject": { "contents": { "type": { - "repr": "0x0000000000000000000000000000000000000000000000000000000000000002::coin::Coin<0x0000000000000000000000000000000000000000000000000000000000000002::iota::IOTA>" + "repr": "0xb13cb331988d6067f70d5a1c715be0203ff1cec6983c481196f0225e9da9bda1::m::Foo" }, "json": { - "id": "0x74b6c16a640092f327aa742a3f444c8a9c0e99e048736735e99e0639202f07da", - "balance": { - "value": "2000" - } + "id": "0xfc0517b5eab059e852955967e0fd4fd317548abc3c0aaed13a339ef1d883748f", + "xs": [ + "42", + "43" + ] } } } @@ -837,7 +837,7 @@ Response: { }, "gasEffects": { "gasObject": { - "address": "0x16a8e888439fb865e2ebb65d890e872be6717414f401f079b5741e67467ca41c" + "address": "0x5c1292f982e4f4162d6bda7f92177d35c6d0cfbb5b5317a91269d060fb7aa7af" }, "gasSummary": { "computationCost": "1000000", @@ -854,7 +854,7 @@ Response: { "sequenceNumber": 3 }, "transactionBlock": { - "digest": "JDtQReNP9NNFzaR91VpSitkB1cw11g41n4ieVCcLW2Ke" + "digest": "7ScQwMi7B9V5EgXAZMJpmTWztT4fZJN7BFWStEkW69Cr" } }, "expiration": null @@ -881,12 +881,12 @@ Response: { "transactionBlocks": { "nodes": [ { - "digest": "3sWb5ikHtuVYUoRg7WecPj4cj3UzuZJgz6wW8yA9Hp9o", + "digest": "7dyDFF4HApyHC4NUYRykLWRBGcZkEBJPFKTWR7NGnqbf", "sender": { "address": "0x8cca4e1ce0ba5904cea61df9242da2f7d29e3ef328fb7ec07c086b3bf47ca61a" }, "signatures": [ - "ACOUIjr22KZzZZ+i1I00zWbnlDdRakWNKcqjb47IQW6AvdSGdbxz4Lx/U+3oyhrAma/jwV/yiWdmSeDooErZtAF/UUY663bYjcm3XmNyULIgxJz1t5Z9vxfB+fp8WUoJKA==" + "APsRYujXA9MTo750KANcVG2sEvE+mMWhO0AMmgUmPXykaI8LSKjfTyg1dkdpGbRIMviGdNH6EjFt4JK87KDIywR/UUY663bYjcm3XmNyULIgxJz1t5Z9vxfB+fp8WUoJKA==" ], "gasInput": { "gasSponsor": { @@ -895,7 +895,7 @@ Response: { "gasPayment": { "nodes": [ { - "address": "0x16a8e888439fb865e2ebb65d890e872be6717414f401f079b5741e67467ca41c" + "address": "0x5c1292f982e4f4162d6bda7f92177d35c6d0cfbb5b5317a91269d060fb7aa7af" } ] }, @@ -942,7 +942,7 @@ Response: { "dependencies": { "nodes": [ { - "digest": "JDtQReNP9NNFzaR91VpSitkB1cw11g41n4ieVCcLW2Ke" + "digest": "7ScQwMi7B9V5EgXAZMJpmTWztT4fZJN7BFWStEkW69Cr" } ] }, @@ -962,19 +962,19 @@ Response: { "objectChanges": { "nodes": [ { - "address": "0x16a8e888439fb865e2ebb65d890e872be6717414f401f079b5741e67467ca41c", + "address": "0x5c1292f982e4f4162d6bda7f92177d35c6d0cfbb5b5317a91269d060fb7aa7af", "idCreated": false, "idDeleted": false, "outputState": { - "address": "0x16a8e888439fb865e2ebb65d890e872be6717414f401f079b5741e67467ca41c", - "digest": "8uEkTALwnaXWBEX7WYE5WcA7iZDwDnU1txGPvu2qHM8t" + "address": "0x5c1292f982e4f4162d6bda7f92177d35c6d0cfbb5b5317a91269d060fb7aa7af", + "digest": "8cZJp6TcRA3d36RZYYAAayxEkrvkafwzC5FQsX6gxZUr" } } ] }, "gasEffects": { "gasObject": { - "address": "0x16a8e888439fb865e2ebb65d890e872be6717414f401f079b5741e67467ca41c" + "address": "0x5c1292f982e4f4162d6bda7f92177d35c6d0cfbb5b5317a91269d060fb7aa7af" }, "gasSummary": { "computationCost": "1000000", @@ -991,7 +991,7 @@ Response: { "sequenceNumber": 4 }, "transactionBlock": { - "digest": "3sWb5ikHtuVYUoRg7WecPj4cj3UzuZJgz6wW8yA9Hp9o" + "digest": "7dyDFF4HApyHC4NUYRykLWRBGcZkEBJPFKTWR7NGnqbf" } }, "expiration": null diff --git a/crates/iota-graphql-e2e-tests/tests/transactions/random.exp b/crates/iota-graphql-e2e-tests/tests/transactions/random.exp index ebeb8b8e7d7..ea36ea21514 100644 --- a/crates/iota-graphql-e2e-tests/tests/transactions/random.exp +++ b/crates/iota-graphql-e2e-tests/tests/transactions/random.exp @@ -19,7 +19,7 @@ Response: { "json": { "id": "0x0000000000000000000000000000000000000000000000000000000000000008", "inner": { - "id": "0x0a4818932295cdda8e2bf2bdf2af0d8022da23aafcc2a3a671f0db8a18a40914", + "id": "0x3ea5f6c162a25be99c5853e0d393a986af600b290c1c48ce6896602d36115385", "version": "1" } } diff --git a/crates/iota-graphql-e2e-tests/tests/transactions/scan_limit/alternating.exp b/crates/iota-graphql-e2e-tests/tests/transactions/scan_limit/alternating.exp index 2f8cca14658..b6339352d48 100644 --- a/crates/iota-graphql-e2e-tests/tests/transactions/scan_limit/alternating.exp +++ b/crates/iota-graphql-e2e-tests/tests/transactions/scan_limit/alternating.exp @@ -96,7 +96,7 @@ Response: { { "cursor": "eyJjIjozLCJ0IjoyLCJpIjpmYWxzZX0", "node": { - "digest": "EqqWSPU9Xpov2yDutF8bhtMpkbqB66Ct3AN8sMJWBUCu", + "digest": "3wzRVqK1eXohkhxfHurLNoxT7GtMtvqzDeBDxxmswVJU", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -124,7 +124,7 @@ Response: { { "cursor": "eyJjIjozLCJ0Ijo0LCJpIjpmYWxzZX0", "node": { - "digest": "5wW9eGhGKPoDfUxsiWHTgcxDBz34QD7Fc6cMiMEqwMW", + "digest": "7qVK75EL3CwAFnYkskDSc4bH3p9fihdzk2N5qH5TH3WH", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -135,7 +135,7 @@ Response: { { "cursor": "eyJjIjozLCJ0Ijo2LCJpIjpmYWxzZX0", "node": { - "digest": "DvLhb1b8EgZnnqHeJewPu5wcySe1Emthar62n68G2JeA", + "digest": "GF6RDKf6T3QzjyEvgXjwDUGivbugjgtoaaJgnRJjrMmj", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -163,7 +163,7 @@ Response: { { "cursor": "eyJjIjozLCJ0Ijo0LCJpIjpmYWxzZX0", "node": { - "digest": "5wW9eGhGKPoDfUxsiWHTgcxDBz34QD7Fc6cMiMEqwMW", + "digest": "7qVK75EL3CwAFnYkskDSc4bH3p9fihdzk2N5qH5TH3WH", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -191,7 +191,7 @@ Response: { { "cursor": "eyJjIjozLCJ0Ijo4LCJpIjpmYWxzZX0", "node": { - "digest": "4JVs5UtEghNfT8MhBCxi5Dqc64sb2qM3gKynVrrDSnvM", + "digest": "AGJCoFvR9E9Hu8DgiVb4YjGh8BQoztVAT4njj6epasgy", "effects": { "checkpoint": { "sequenceNumber": 3 @@ -219,7 +219,7 @@ Response: { { "cursor": "eyJjIjozLCJ0Ijo2LCJpIjpmYWxzZX0", "node": { - "digest": "DvLhb1b8EgZnnqHeJewPu5wcySe1Emthar62n68G2JeA", + "digest": "GF6RDKf6T3QzjyEvgXjwDUGivbugjgtoaaJgnRJjrMmj", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -230,7 +230,7 @@ Response: { { "cursor": "eyJjIjozLCJ0Ijo4LCJpIjpmYWxzZX0", "node": { - "digest": "4JVs5UtEghNfT8MhBCxi5Dqc64sb2qM3gKynVrrDSnvM", + "digest": "AGJCoFvR9E9Hu8DgiVb4YjGh8BQoztVAT4njj6epasgy", "effects": { "checkpoint": { "sequenceNumber": 3 @@ -258,7 +258,7 @@ Response: { { "cursor": "eyJjIjozLCJ0IjoxMCwiaSI6ZmFsc2V9", "node": { - "digest": "FjEwv7uuizMyfXs2xHPRkTUHKhyAL7W9yGHGTBV7uwMW", + "digest": "G4DQGY8uNqmuvgNUfgZsUgygYsm7uYTmJqeVS3KQce7T", "effects": { "checkpoint": { "sequenceNumber": 3 @@ -286,7 +286,7 @@ Response: { { "cursor": "eyJjIjozLCJ0IjoxMCwiaSI6ZmFsc2V9", "node": { - "digest": "FjEwv7uuizMyfXs2xHPRkTUHKhyAL7W9yGHGTBV7uwMW", + "digest": "G4DQGY8uNqmuvgNUfgZsUgygYsm7uYTmJqeVS3KQce7T", "effects": { "checkpoint": { "sequenceNumber": 3 diff --git a/crates/iota-graphql-e2e-tests/tests/transactions/scan_limit/both_cursors.exp b/crates/iota-graphql-e2e-tests/tests/transactions/scan_limit/both_cursors.exp index 34bdb4c1234..5db8f2df403 100644 --- a/crates/iota-graphql-e2e-tests/tests/transactions/scan_limit/both_cursors.exp +++ b/crates/iota-graphql-e2e-tests/tests/transactions/scan_limit/both_cursors.exp @@ -96,7 +96,7 @@ Response: { { "cursor": "eyJjIjo0LCJ0Ijo0LCJpIjpmYWxzZX0", "node": { - "digest": "EjHhzapgKBFRNw7b6w1Ug7FPYjDZZgPvtwb3BVzu9HVw", + "digest": "CG7koKCHyRYi8AFPnKoKVBQkM8MJzSmCnWwM2XGRCbab", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -124,7 +124,7 @@ Response: { { "cursor": "eyJjIjo0LCJ0Ijo0LCJpIjpmYWxzZX0", "node": { - "digest": "EjHhzapgKBFRNw7b6w1Ug7FPYjDZZgPvtwb3BVzu9HVw", + "digest": "CG7koKCHyRYi8AFPnKoKVBQkM8MJzSmCnWwM2XGRCbab", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -135,7 +135,7 @@ Response: { { "cursor": "eyJjIjo0LCJ0Ijo2LCJpIjpmYWxzZX0", "node": { - "digest": "3YkKM9NR6VoFxtnDP4QgVvCUmda7paoXjse17LjsVqH5", + "digest": "7ym2EAwHQ6uwKP6Kf8gvmo8oJGoGvaiNKNH9iQdAHUmq", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -163,7 +163,7 @@ Response: { { "cursor": "eyJjIjo0LCJ0Ijo1LCJpIjpmYWxzZX0", "node": { - "digest": "AjYmhGr6j3jYSES2NVkd57p973gwa3UZbh2tv9QK6S2m", + "digest": "4sC14KitR3PTk2aGHS8zdGRTZcruQSweWXY1P7mfYTLW", "effects": { "checkpoint": { "sequenceNumber": 2 diff --git a/crates/iota-graphql-e2e-tests/tests/transactions/scan_limit/equal/first.exp b/crates/iota-graphql-e2e-tests/tests/transactions/scan_limit/equal/first.exp index ee5efca31d1..a7fc41d8452 100644 --- a/crates/iota-graphql-e2e-tests/tests/transactions/scan_limit/equal/first.exp +++ b/crates/iota-graphql-e2e-tests/tests/transactions/scan_limit/equal/first.exp @@ -96,7 +96,7 @@ Response: { { "cursor": "eyJjIjozLCJ0IjoyLCJpIjpmYWxzZX0", "node": { - "digest": "Fpc7N9qYBCegSxBgmmEwANpQecoRmNriyNnA1WCgZ7T9", + "digest": "HN64Vz8PmNEztyXSjqgeC7BazCvvdHT9BN62t9WJJiiD", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -107,7 +107,7 @@ Response: { { "cursor": "eyJjIjozLCJ0Ijo0LCJpIjpmYWxzZX0", "node": { - "digest": "EjHhzapgKBFRNw7b6w1Ug7FPYjDZZgPvtwb3BVzu9HVw", + "digest": "CG7koKCHyRYi8AFPnKoKVBQkM8MJzSmCnWwM2XGRCbab", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -118,7 +118,7 @@ Response: { { "cursor": "eyJjIjozLCJ0Ijo2LCJpIjpmYWxzZX0", "node": { - "digest": "3YkKM9NR6VoFxtnDP4QgVvCUmda7paoXjse17LjsVqH5", + "digest": "7ym2EAwHQ6uwKP6Kf8gvmo8oJGoGvaiNKNH9iQdAHUmq", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -129,7 +129,7 @@ Response: { { "cursor": "eyJjIjozLCJ0IjoxMCwiaSI6ZmFsc2V9", "node": { - "digest": "Ejp4Gnf3Gw8A3GpDDSEK1dTFXckwp6gs2bMnysHPMrzm", + "digest": "2A5RGEPYgUn7GbamdVBXWLzokKQStup1DNzqkxQqqmgW", "effects": { "checkpoint": { "sequenceNumber": 3 @@ -140,7 +140,7 @@ Response: { { "cursor": "eyJjIjozLCJ0IjoxMSwiaSI6ZmFsc2V9", "node": { - "digest": "4MTQKdLBaFpFGTLpFqWHjeWmzuvCmbiDuqp6uRi8wBfx", + "digest": "7WTn3jXerZU2jTq9JWjgS75U2w4ayK5eNzUxegW4qpTq", "effects": { "checkpoint": { "sequenceNumber": 3 @@ -168,7 +168,7 @@ Response: { { "cursor": "eyJjIjozLCJ0IjoyLCJpIjpmYWxzZX0", "node": { - "digest": "Fpc7N9qYBCegSxBgmmEwANpQecoRmNriyNnA1WCgZ7T9", + "digest": "HN64Vz8PmNEztyXSjqgeC7BazCvvdHT9BN62t9WJJiiD", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -196,7 +196,7 @@ Response: { { "cursor": "eyJjIjo0LCJ0Ijo0LCJpIjpmYWxzZX0", "node": { - "digest": "EjHhzapgKBFRNw7b6w1Ug7FPYjDZZgPvtwb3BVzu9HVw", + "digest": "CG7koKCHyRYi8AFPnKoKVBQkM8MJzSmCnWwM2XGRCbab", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -224,7 +224,7 @@ Response: { { "cursor": "eyJjIjo0LCJ0Ijo2LCJpIjpmYWxzZX0", "node": { - "digest": "3YkKM9NR6VoFxtnDP4QgVvCUmda7paoXjse17LjsVqH5", + "digest": "7ym2EAwHQ6uwKP6Kf8gvmo8oJGoGvaiNKNH9iQdAHUmq", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -268,7 +268,7 @@ Response: { { "cursor": "eyJjIjo0LCJ0IjoxMCwiaSI6ZmFsc2V9", "node": { - "digest": "Ejp4Gnf3Gw8A3GpDDSEK1dTFXckwp6gs2bMnysHPMrzm", + "digest": "2A5RGEPYgUn7GbamdVBXWLzokKQStup1DNzqkxQqqmgW", "effects": { "checkpoint": { "sequenceNumber": 3 @@ -279,7 +279,7 @@ Response: { { "cursor": "eyJjIjo0LCJ0IjoxMSwiaSI6ZmFsc2V9", "node": { - "digest": "4MTQKdLBaFpFGTLpFqWHjeWmzuvCmbiDuqp6uRi8wBfx", + "digest": "7WTn3jXerZU2jTq9JWjgS75U2w4ayK5eNzUxegW4qpTq", "effects": { "checkpoint": { "sequenceNumber": 3 @@ -333,7 +333,7 @@ Response: { { "cursor": "eyJjIjo0LCJ0IjoxMCwiaSI6ZmFsc2V9", "node": { - "digest": "Ejp4Gnf3Gw8A3GpDDSEK1dTFXckwp6gs2bMnysHPMrzm", + "digest": "2A5RGEPYgUn7GbamdVBXWLzokKQStup1DNzqkxQqqmgW", "effects": { "checkpoint": { "sequenceNumber": 3 @@ -344,7 +344,7 @@ Response: { { "cursor": "eyJjIjo0LCJ0IjoxMSwiaSI6ZmFsc2V9", "node": { - "digest": "4MTQKdLBaFpFGTLpFqWHjeWmzuvCmbiDuqp6uRi8wBfx", + "digest": "7WTn3jXerZU2jTq9JWjgS75U2w4ayK5eNzUxegW4qpTq", "effects": { "checkpoint": { "sequenceNumber": 3 diff --git a/crates/iota-graphql-e2e-tests/tests/transactions/scan_limit/equal/last.exp b/crates/iota-graphql-e2e-tests/tests/transactions/scan_limit/equal/last.exp index 1d598558f67..3bad80a971e 100644 --- a/crates/iota-graphql-e2e-tests/tests/transactions/scan_limit/equal/last.exp +++ b/crates/iota-graphql-e2e-tests/tests/transactions/scan_limit/equal/last.exp @@ -96,7 +96,7 @@ Response: { { "cursor": "eyJjIjozLCJ0IjoyLCJpIjpmYWxzZX0", "node": { - "digest": "Fpc7N9qYBCegSxBgmmEwANpQecoRmNriyNnA1WCgZ7T9", + "digest": "HN64Vz8PmNEztyXSjqgeC7BazCvvdHT9BN62t9WJJiiD", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -107,7 +107,7 @@ Response: { { "cursor": "eyJjIjozLCJ0IjozLCJpIjpmYWxzZX0", "node": { - "digest": "FirY733kBLzzbcnFsSPoeWLWAYBA1DcjHcurF9X1yxWa", + "digest": "14Dp55F4CcoMwSXo9UJJj9rLWHHrsh55u1bG8AyJzf29", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -118,7 +118,7 @@ Response: { { "cursor": "eyJjIjozLCJ0Ijo3LCJpIjpmYWxzZX0", "node": { - "digest": "7xVbGwKZMhSTY8fc9AhmcxsSagqiN55EgWstg8tzJRDg", + "digest": "5ijxkCKmY5GhbDpZ8EUT5cEHCPrhSxmySCsy9P7hdnav", "effects": { "checkpoint": { "sequenceNumber": 3 @@ -129,7 +129,7 @@ Response: { { "cursor": "eyJjIjozLCJ0Ijo5LCJpIjpmYWxzZX0", "node": { - "digest": "FCX74CUei7vEA5kENiNyRGsWg2KuPNfyy1U81yRgnt1P", + "digest": "GL1RzmY36Heq6Ep8b3TB8gggSPJfDXHXHLG1cEMpeiaQ", "effects": { "checkpoint": { "sequenceNumber": 3 @@ -140,7 +140,7 @@ Response: { { "cursor": "eyJjIjozLCJ0IjoxMSwiaSI6ZmFsc2V9", "node": { - "digest": "MWWXrHgPzcyTSU7qoV7QAwTcrwLt2djL5qHWED2354v", + "digest": "8gsWcWUrsfT2XoA1sztv3dLLM6h47ZqiMf2VPutUrt33", "effects": { "checkpoint": { "sequenceNumber": 3 @@ -168,7 +168,7 @@ Response: { { "cursor": "eyJjIjozLCJ0IjoxMSwiaSI6ZmFsc2V9", "node": { - "digest": "MWWXrHgPzcyTSU7qoV7QAwTcrwLt2djL5qHWED2354v", + "digest": "8gsWcWUrsfT2XoA1sztv3dLLM6h47ZqiMf2VPutUrt33", "effects": { "checkpoint": { "sequenceNumber": 3 @@ -196,7 +196,7 @@ Response: { { "cursor": "eyJjIjo0LCJ0Ijo5LCJpIjpmYWxzZX0", "node": { - "digest": "FCX74CUei7vEA5kENiNyRGsWg2KuPNfyy1U81yRgnt1P", + "digest": "GL1RzmY36Heq6Ep8b3TB8gggSPJfDXHXHLG1cEMpeiaQ", "effects": { "checkpoint": { "sequenceNumber": 3 @@ -224,7 +224,7 @@ Response: { { "cursor": "eyJjIjo0LCJ0Ijo3LCJpIjpmYWxzZX0", "node": { - "digest": "7xVbGwKZMhSTY8fc9AhmcxsSagqiN55EgWstg8tzJRDg", + "digest": "5ijxkCKmY5GhbDpZ8EUT5cEHCPrhSxmySCsy9P7hdnav", "effects": { "checkpoint": { "sequenceNumber": 3 @@ -268,7 +268,7 @@ Response: { { "cursor": "eyJjIjo0LCJ0IjoyLCJpIjpmYWxzZX0", "node": { - "digest": "Fpc7N9qYBCegSxBgmmEwANpQecoRmNriyNnA1WCgZ7T9", + "digest": "HN64Vz8PmNEztyXSjqgeC7BazCvvdHT9BN62t9WJJiiD", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -279,7 +279,7 @@ Response: { { "cursor": "eyJjIjo0LCJ0IjozLCJpIjpmYWxzZX0", "node": { - "digest": "FirY733kBLzzbcnFsSPoeWLWAYBA1DcjHcurF9X1yxWa", + "digest": "14Dp55F4CcoMwSXo9UJJj9rLWHHrsh55u1bG8AyJzf29", "effects": { "checkpoint": { "sequenceNumber": 2 diff --git a/crates/iota-graphql-e2e-tests/tests/transactions/scan_limit/ge_page/first.exp b/crates/iota-graphql-e2e-tests/tests/transactions/scan_limit/ge_page/first.exp index 0fa196e86e5..4cccc349430 100644 --- a/crates/iota-graphql-e2e-tests/tests/transactions/scan_limit/ge_page/first.exp +++ b/crates/iota-graphql-e2e-tests/tests/transactions/scan_limit/ge_page/first.exp @@ -164,7 +164,7 @@ Response: { { "cursor": "eyJjIjo1LCJ0IjoyLCJpIjpmYWxzZX0", "node": { - "digest": "EqqWSPU9Xpov2yDutF8bhtMpkbqB66Ct3AN8sMJWBUCu", + "digest": "3wzRVqK1eXohkhxfHurLNoxT7GtMtvqzDeBDxxmswVJU", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -175,7 +175,7 @@ Response: { { "cursor": "eyJjIjo1LCJ0IjozLCJpIjpmYWxzZX0", "node": { - "digest": "3B8UsX3diudqqgPmkuwremUc5cR49mJkxdPzfLUJ1BGq", + "digest": "6y9UF1snskP2LXvGksRVjXJqTaNS7ADtizyQaVXSVn16", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -186,7 +186,7 @@ Response: { { "cursor": "eyJjIjo1LCJ0IjoxNywiaSI6ZmFsc2V9", "node": { - "digest": "FvrRt4VHFqh8RtDtR3FPwiDAbt1VuV1aS9bJyp3DSnu8", + "digest": "nxC5491CFRQaXhrs1YfTj9hqGg4apLs8aLrWDY1xxu3", "effects": { "checkpoint": { "sequenceNumber": 5 @@ -197,7 +197,7 @@ Response: { { "cursor": "eyJjIjo1LCJ0IjoxOCwiaSI6ZmFsc2V9", "node": { - "digest": "3bQyYzXuE22XcazmaR9fb48yyAXHwazXqzszfSvj1CnH", + "digest": "D9bZNc9AmSiAMDE5kJTxgQqhQcstsokmBA4Mq4QqQGUx", "effects": { "checkpoint": { "sequenceNumber": 5 @@ -208,7 +208,7 @@ Response: { { "cursor": "eyJjIjo1LCJ0IjoyMSwiaSI6ZmFsc2V9", "node": { - "digest": "99chatBJVEwgJFy2cLCpEafTSgcs3kYjsjm8WymdLmdY", + "digest": "BBZrmvswLx4LbYNzKZAH5bGFp8PihXWvNLnaBZNLN6kZ", "effects": { "checkpoint": { "sequenceNumber": 5 @@ -236,7 +236,7 @@ Response: { { "cursor": "eyJjIjo1LCJ0IjoyLCJpIjpmYWxzZX0", "node": { - "digest": "EqqWSPU9Xpov2yDutF8bhtMpkbqB66Ct3AN8sMJWBUCu", + "digest": "3wzRVqK1eXohkhxfHurLNoxT7GtMtvqzDeBDxxmswVJU", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -264,7 +264,7 @@ Response: { { "cursor": "eyJjIjo3LCJ0IjozLCJpIjpmYWxzZX0", "node": { - "digest": "3B8UsX3diudqqgPmkuwremUc5cR49mJkxdPzfLUJ1BGq", + "digest": "6y9UF1snskP2LXvGksRVjXJqTaNS7ADtizyQaVXSVn16", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -308,7 +308,7 @@ Response: { { "cursor": "eyJjIjo3LCJ0IjoxNywiaSI6ZmFsc2V9", "node": { - "digest": "FvrRt4VHFqh8RtDtR3FPwiDAbt1VuV1aS9bJyp3DSnu8", + "digest": "nxC5491CFRQaXhrs1YfTj9hqGg4apLs8aLrWDY1xxu3", "effects": { "checkpoint": { "sequenceNumber": 5 @@ -336,7 +336,7 @@ Response: { { "cursor": "eyJjIjo3LCJ0IjoxOCwiaSI6ZmFsc2V9", "node": { - "digest": "3bQyYzXuE22XcazmaR9fb48yyAXHwazXqzszfSvj1CnH", + "digest": "D9bZNc9AmSiAMDE5kJTxgQqhQcstsokmBA4Mq4QqQGUx", "effects": { "checkpoint": { "sequenceNumber": 5 @@ -364,7 +364,7 @@ Response: { { "cursor": "eyJjIjo3LCJ0IjoyMSwiaSI6ZmFsc2V9", "node": { - "digest": "99chatBJVEwgJFy2cLCpEafTSgcs3kYjsjm8WymdLmdY", + "digest": "BBZrmvswLx4LbYNzKZAH5bGFp8PihXWvNLnaBZNLN6kZ", "effects": { "checkpoint": { "sequenceNumber": 5 diff --git a/crates/iota-graphql-e2e-tests/tests/transactions/scan_limit/ge_page/last.exp b/crates/iota-graphql-e2e-tests/tests/transactions/scan_limit/ge_page/last.exp index 69ef41256cf..ef9a1dd3b8c 100644 --- a/crates/iota-graphql-e2e-tests/tests/transactions/scan_limit/ge_page/last.exp +++ b/crates/iota-graphql-e2e-tests/tests/transactions/scan_limit/ge_page/last.exp @@ -164,7 +164,7 @@ Response: { { "cursor": "eyJjIjo1LCJ0IjoyLCJpIjpmYWxzZX0", "node": { - "digest": "EqqWSPU9Xpov2yDutF8bhtMpkbqB66Ct3AN8sMJWBUCu", + "digest": "3wzRVqK1eXohkhxfHurLNoxT7GtMtvqzDeBDxxmswVJU", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -175,7 +175,7 @@ Response: { { "cursor": "eyJjIjo1LCJ0IjozLCJpIjpmYWxzZX0", "node": { - "digest": "3B8UsX3diudqqgPmkuwremUc5cR49mJkxdPzfLUJ1BGq", + "digest": "6y9UF1snskP2LXvGksRVjXJqTaNS7ADtizyQaVXSVn16", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -186,7 +186,7 @@ Response: { { "cursor": "eyJjIjo1LCJ0IjoxNywiaSI6ZmFsc2V9", "node": { - "digest": "FvrRt4VHFqh8RtDtR3FPwiDAbt1VuV1aS9bJyp3DSnu8", + "digest": "nxC5491CFRQaXhrs1YfTj9hqGg4apLs8aLrWDY1xxu3", "effects": { "checkpoint": { "sequenceNumber": 5 @@ -197,7 +197,7 @@ Response: { { "cursor": "eyJjIjo1LCJ0IjoyMSwiaSI6ZmFsc2V9", "node": { - "digest": "Hjqv7QdSM2G2yfurdHv36unknXNu1JnoHjJcW2UsYwVq", + "digest": "78XKtEqaRGRjsrF8PEBRpcJ22AmzaZtat3NmeCwc2kpD", "effects": { "checkpoint": { "sequenceNumber": 5 @@ -225,7 +225,7 @@ Response: { { "cursor": "eyJjIjo1LCJ0IjoyMSwiaSI6ZmFsc2V9", "node": { - "digest": "Hjqv7QdSM2G2yfurdHv36unknXNu1JnoHjJcW2UsYwVq", + "digest": "78XKtEqaRGRjsrF8PEBRpcJ22AmzaZtat3NmeCwc2kpD", "effects": { "checkpoint": { "sequenceNumber": 5 @@ -253,7 +253,7 @@ Response: { { "cursor": "eyJjIjo3LCJ0IjoxNywiaSI6ZmFsc2V9", "node": { - "digest": "FvrRt4VHFqh8RtDtR3FPwiDAbt1VuV1aS9bJyp3DSnu8", + "digest": "nxC5491CFRQaXhrs1YfTj9hqGg4apLs8aLrWDY1xxu3", "effects": { "checkpoint": { "sequenceNumber": 5 @@ -313,7 +313,7 @@ Response: { { "cursor": "eyJjIjo3LCJ0IjozLCJpIjpmYWxzZX0", "node": { - "digest": "3B8UsX3diudqqgPmkuwremUc5cR49mJkxdPzfLUJ1BGq", + "digest": "6y9UF1snskP2LXvGksRVjXJqTaNS7ADtizyQaVXSVn16", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -341,7 +341,7 @@ Response: { { "cursor": "eyJjIjo3LCJ0IjoyLCJpIjpmYWxzZX0", "node": { - "digest": "EqqWSPU9Xpov2yDutF8bhtMpkbqB66Ct3AN8sMJWBUCu", + "digest": "3wzRVqK1eXohkhxfHurLNoxT7GtMtvqzDeBDxxmswVJU", "effects": { "checkpoint": { "sequenceNumber": 2 diff --git a/crates/iota-graphql-e2e-tests/tests/transactions/scan_limit/le_page/first.exp b/crates/iota-graphql-e2e-tests/tests/transactions/scan_limit/le_page/first.exp index 94613b6858d..f147fc6aa7e 100644 --- a/crates/iota-graphql-e2e-tests/tests/transactions/scan_limit/le_page/first.exp +++ b/crates/iota-graphql-e2e-tests/tests/transactions/scan_limit/le_page/first.exp @@ -96,7 +96,7 @@ Response: { { "cursor": "eyJjIjozLCJ0IjoyLCJpIjpmYWxzZX0", "node": { - "digest": "EqqWSPU9Xpov2yDutF8bhtMpkbqB66Ct3AN8sMJWBUCu", + "digest": "3wzRVqK1eXohkhxfHurLNoxT7GtMtvqzDeBDxxmswVJU", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -107,7 +107,7 @@ Response: { { "cursor": "eyJjIjozLCJ0IjozLCJpIjpmYWxzZX0", "node": { - "digest": "8yc9oAm3R4131ZyaFPmyUpzQR5gz42Bin7ADTqjvRnCx", + "digest": "2Ti9BKLVNTkifpJUXhXtYRe4o4HM1Hnsv977TXgxtnbP", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -118,7 +118,7 @@ Response: { { "cursor": "eyJjIjozLCJ0Ijo0LCJpIjpmYWxzZX0", "node": { - "digest": "5wW9eGhGKPoDfUxsiWHTgcxDBz34QD7Fc6cMiMEqwMW", + "digest": "7qVK75EL3CwAFnYkskDSc4bH3p9fihdzk2N5qH5TH3WH", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -129,7 +129,7 @@ Response: { { "cursor": "eyJjIjozLCJ0Ijo1LCJpIjpmYWxzZX0", "node": { - "digest": "D6AUvEYJVe6aZsxRn1CqcPLFbcuLKskfrSY1jMYNR2Ha", + "digest": "BHxSqDRAs12PCjUVE8Xxrmq8ddhL8RLW1EnqJipprim", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -140,7 +140,7 @@ Response: { { "cursor": "eyJjIjozLCJ0Ijo2LCJpIjpmYWxzZX0", "node": { - "digest": "DvLhb1b8EgZnnqHeJewPu5wcySe1Emthar62n68G2JeA", + "digest": "GF6RDKf6T3QzjyEvgXjwDUGivbugjgtoaaJgnRJjrMmj", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -151,7 +151,7 @@ Response: { { "cursor": "eyJjIjozLCJ0Ijo3LCJpIjpmYWxzZX0", "node": { - "digest": "96n3Rq5QnAGcXPHsom5kMHiWorsd28yAcjTpjKU2mDht", + "digest": "Dqpsd6xzFPoLC6iKK2kyYZmfuAnaDkUKa4QaWBTA9DUk", "effects": { "checkpoint": { "sequenceNumber": 3 @@ -162,7 +162,7 @@ Response: { { "cursor": "eyJjIjozLCJ0Ijo4LCJpIjpmYWxzZX0", "node": { - "digest": "4JVs5UtEghNfT8MhBCxi5Dqc64sb2qM3gKynVrrDSnvM", + "digest": "AGJCoFvR9E9Hu8DgiVb4YjGh8BQoztVAT4njj6epasgy", "effects": { "checkpoint": { "sequenceNumber": 3 @@ -173,7 +173,7 @@ Response: { { "cursor": "eyJjIjozLCJ0Ijo5LCJpIjpmYWxzZX0", "node": { - "digest": "85YmFDGF6qzNkXjeXwqfguzjopXQk4Yo6S7rizt5BXSH", + "digest": "6VJkYFBeAe8PydrD4BFcdKEGCMjzePgPViRzBzPydyMT", "effects": { "checkpoint": { "sequenceNumber": 3 @@ -184,7 +184,7 @@ Response: { { "cursor": "eyJjIjozLCJ0IjoxMCwiaSI6ZmFsc2V9", "node": { - "digest": "FjEwv7uuizMyfXs2xHPRkTUHKhyAL7W9yGHGTBV7uwMW", + "digest": "G4DQGY8uNqmuvgNUfgZsUgygYsm7uYTmJqeVS3KQce7T", "effects": { "checkpoint": { "sequenceNumber": 3 @@ -195,7 +195,7 @@ Response: { { "cursor": "eyJjIjozLCJ0IjoxMSwiaSI6ZmFsc2V9", "node": { - "digest": "4DpnvwQZvwxPUBVmBDntFc5ie5L2kA6W2GWU6NtG5dzm", + "digest": "G4ETt5JzNXD4KgULBkhVEPN3p2qcneov6idAVXtFEk7g", "effects": { "checkpoint": { "sequenceNumber": 3 @@ -223,7 +223,7 @@ Response: { { "cursor": "eyJjIjozLCJ0IjoyLCJpIjpmYWxzZX0", "node": { - "digest": "EqqWSPU9Xpov2yDutF8bhtMpkbqB66Ct3AN8sMJWBUCu", + "digest": "3wzRVqK1eXohkhxfHurLNoxT7GtMtvqzDeBDxxmswVJU", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -251,7 +251,7 @@ Response: { { "cursor": "eyJjIjo0LCJ0Ijo0LCJpIjpmYWxzZX0", "node": { - "digest": "5wW9eGhGKPoDfUxsiWHTgcxDBz34QD7Fc6cMiMEqwMW", + "digest": "7qVK75EL3CwAFnYkskDSc4bH3p9fihdzk2N5qH5TH3WH", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -279,7 +279,7 @@ Response: { { "cursor": "eyJjIjo0LCJ0Ijo2LCJpIjpmYWxzZX0", "node": { - "digest": "DvLhb1b8EgZnnqHeJewPu5wcySe1Emthar62n68G2JeA", + "digest": "GF6RDKf6T3QzjyEvgXjwDUGivbugjgtoaaJgnRJjrMmj", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -290,7 +290,7 @@ Response: { { "cursor": "eyJjIjo0LCJ0Ijo4LCJpIjpmYWxzZX0", "node": { - "digest": "4JVs5UtEghNfT8MhBCxi5Dqc64sb2qM3gKynVrrDSnvM", + "digest": "AGJCoFvR9E9Hu8DgiVb4YjGh8BQoztVAT4njj6epasgy", "effects": { "checkpoint": { "sequenceNumber": 3 @@ -318,7 +318,7 @@ Response: { { "cursor": "eyJjIjo0LCJ0IjoxMCwiaSI6ZmFsc2V9", "node": { - "digest": "FjEwv7uuizMyfXs2xHPRkTUHKhyAL7W9yGHGTBV7uwMW", + "digest": "G4DQGY8uNqmuvgNUfgZsUgygYsm7uYTmJqeVS3KQce7T", "effects": { "checkpoint": { "sequenceNumber": 3 diff --git a/crates/iota-graphql-e2e-tests/tests/transactions/scan_limit/le_page/last.exp b/crates/iota-graphql-e2e-tests/tests/transactions/scan_limit/le_page/last.exp index 1017c645ef0..4b01bc01e9b 100644 --- a/crates/iota-graphql-e2e-tests/tests/transactions/scan_limit/le_page/last.exp +++ b/crates/iota-graphql-e2e-tests/tests/transactions/scan_limit/le_page/last.exp @@ -96,7 +96,7 @@ Response: { { "cursor": "eyJjIjozLCJ0IjoyLCJpIjpmYWxzZX0", "node": { - "digest": "EqqWSPU9Xpov2yDutF8bhtMpkbqB66Ct3AN8sMJWBUCu", + "digest": "3wzRVqK1eXohkhxfHurLNoxT7GtMtvqzDeBDxxmswVJU", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -107,7 +107,7 @@ Response: { { "cursor": "eyJjIjozLCJ0IjozLCJpIjpmYWxzZX0", "node": { - "digest": "8yc9oAm3R4131ZyaFPmyUpzQR5gz42Bin7ADTqjvRnCx", + "digest": "2Ti9BKLVNTkifpJUXhXtYRe4o4HM1Hnsv977TXgxtnbP", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -118,7 +118,7 @@ Response: { { "cursor": "eyJjIjozLCJ0Ijo0LCJpIjpmYWxzZX0", "node": { - "digest": "5wW9eGhGKPoDfUxsiWHTgcxDBz34QD7Fc6cMiMEqwMW", + "digest": "7qVK75EL3CwAFnYkskDSc4bH3p9fihdzk2N5qH5TH3WH", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -129,7 +129,7 @@ Response: { { "cursor": "eyJjIjozLCJ0Ijo1LCJpIjpmYWxzZX0", "node": { - "digest": "D6AUvEYJVe6aZsxRn1CqcPLFbcuLKskfrSY1jMYNR2Ha", + "digest": "BHxSqDRAs12PCjUVE8Xxrmq8ddhL8RLW1EnqJipprim", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -140,7 +140,7 @@ Response: { { "cursor": "eyJjIjozLCJ0Ijo2LCJpIjpmYWxzZX0", "node": { - "digest": "DvLhb1b8EgZnnqHeJewPu5wcySe1Emthar62n68G2JeA", + "digest": "GF6RDKf6T3QzjyEvgXjwDUGivbugjgtoaaJgnRJjrMmj", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -151,7 +151,7 @@ Response: { { "cursor": "eyJjIjozLCJ0Ijo3LCJpIjpmYWxzZX0", "node": { - "digest": "96n3Rq5QnAGcXPHsom5kMHiWorsd28yAcjTpjKU2mDht", + "digest": "Dqpsd6xzFPoLC6iKK2kyYZmfuAnaDkUKa4QaWBTA9DUk", "effects": { "checkpoint": { "sequenceNumber": 3 @@ -162,7 +162,7 @@ Response: { { "cursor": "eyJjIjozLCJ0Ijo4LCJpIjpmYWxzZX0", "node": { - "digest": "4JVs5UtEghNfT8MhBCxi5Dqc64sb2qM3gKynVrrDSnvM", + "digest": "AGJCoFvR9E9Hu8DgiVb4YjGh8BQoztVAT4njj6epasgy", "effects": { "checkpoint": { "sequenceNumber": 3 @@ -173,7 +173,7 @@ Response: { { "cursor": "eyJjIjozLCJ0Ijo5LCJpIjpmYWxzZX0", "node": { - "digest": "85YmFDGF6qzNkXjeXwqfguzjopXQk4Yo6S7rizt5BXSH", + "digest": "6VJkYFBeAe8PydrD4BFcdKEGCMjzePgPViRzBzPydyMT", "effects": { "checkpoint": { "sequenceNumber": 3 @@ -184,7 +184,7 @@ Response: { { "cursor": "eyJjIjozLCJ0IjoxMCwiaSI6ZmFsc2V9", "node": { - "digest": "FjEwv7uuizMyfXs2xHPRkTUHKhyAL7W9yGHGTBV7uwMW", + "digest": "G4DQGY8uNqmuvgNUfgZsUgygYsm7uYTmJqeVS3KQce7T", "effects": { "checkpoint": { "sequenceNumber": 3 @@ -195,7 +195,7 @@ Response: { { "cursor": "eyJjIjozLCJ0IjoxMSwiaSI6ZmFsc2V9", "node": { - "digest": "4DpnvwQZvwxPUBVmBDntFc5ie5L2kA6W2GWU6NtG5dzm", + "digest": "G4ETt5JzNXD4KgULBkhVEPN3p2qcneov6idAVXtFEk7g", "effects": { "checkpoint": { "sequenceNumber": 3 @@ -223,7 +223,7 @@ Response: { { "cursor": "eyJjIjozLCJ0IjoxMCwiaSI6ZmFsc2V9", "node": { - "digest": "FjEwv7uuizMyfXs2xHPRkTUHKhyAL7W9yGHGTBV7uwMW", + "digest": "G4DQGY8uNqmuvgNUfgZsUgygYsm7uYTmJqeVS3KQce7T", "effects": { "checkpoint": { "sequenceNumber": 3 @@ -251,7 +251,7 @@ Response: { { "cursor": "eyJjIjo0LCJ0Ijo4LCJpIjpmYWxzZX0", "node": { - "digest": "4JVs5UtEghNfT8MhBCxi5Dqc64sb2qM3gKynVrrDSnvM", + "digest": "AGJCoFvR9E9Hu8DgiVb4YjGh8BQoztVAT4njj6epasgy", "effects": { "checkpoint": { "sequenceNumber": 3 @@ -279,7 +279,7 @@ Response: { { "cursor": "eyJjIjo0LCJ0Ijo2LCJpIjpmYWxzZX0", "node": { - "digest": "DvLhb1b8EgZnnqHeJewPu5wcySe1Emthar62n68G2JeA", + "digest": "GF6RDKf6T3QzjyEvgXjwDUGivbugjgtoaaJgnRJjrMmj", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -307,7 +307,7 @@ Response: { { "cursor": "eyJjIjo0LCJ0Ijo0LCJpIjpmYWxzZX0", "node": { - "digest": "5wW9eGhGKPoDfUxsiWHTgcxDBz34QD7Fc6cMiMEqwMW", + "digest": "7qVK75EL3CwAFnYkskDSc4bH3p9fihdzk2N5qH5TH3WH", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -335,7 +335,7 @@ Response: { { "cursor": "eyJjIjo0LCJ0IjoyLCJpIjpmYWxzZX0", "node": { - "digest": "EqqWSPU9Xpov2yDutF8bhtMpkbqB66Ct3AN8sMJWBUCu", + "digest": "3wzRVqK1eXohkhxfHurLNoxT7GtMtvqzDeBDxxmswVJU", "effects": { "checkpoint": { "sequenceNumber": 2 diff --git a/crates/iota-graphql-e2e-tests/tests/transactions/scan_limit/require.exp b/crates/iota-graphql-e2e-tests/tests/transactions/scan_limit/require.exp index a6d7e6fae03..0c424b3061c 100644 --- a/crates/iota-graphql-e2e-tests/tests/transactions/scan_limit/require.exp +++ b/crates/iota-graphql-e2e-tests/tests/transactions/scan_limit/require.exp @@ -94,7 +94,7 @@ Response: { }, "nodes": [ { - "digest": "Fpc7N9qYBCegSxBgmmEwANpQecoRmNriyNnA1WCgZ7T9", + "digest": "HN64Vz8PmNEztyXSjqgeC7BazCvvdHT9BN62t9WJJiiD", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -102,7 +102,7 @@ Response: { } }, { - "digest": "FirY733kBLzzbcnFsSPoeWLWAYBA1DcjHcurF9X1yxWa", + "digest": "14Dp55F4CcoMwSXo9UJJj9rLWHHrsh55u1bG8AyJzf29", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -110,7 +110,7 @@ Response: { } }, { - "digest": "9K2FJpFUUXiEV8LznzjUQJcY2K4vmX9kECwKas2vsyG", + "digest": "FSFfAaccXApG4NNDNwsvfeWqzZx7WHBtssn7yCpKF7w1", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -118,7 +118,7 @@ Response: { } }, { - "digest": "BwBbnCKP9UAtpPSVV3RZqzozM15AaHDFtoRnpqkWDBMk", + "digest": "432fq3xpYtMXxVMuNcBzPK4ikrpFTEVGEiKLNsjpmczY", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -126,7 +126,7 @@ Response: { } }, { - "digest": "9EdPgfA4esk9eiAHDGuhDSwznBpu4Z35cpEaaADvP5zT", + "digest": "oBvYm41RTyB7u5HGE91QdKNNRw5AYXBrFEDLJTXnN9F", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -134,7 +134,7 @@ Response: { } }, { - "digest": "CxwvRZkjcFEqnFeqT4zQyQwKRpaS1NMnfk6ZHgrcuWEQ", + "digest": "GQEae2TqUmShfWdHzyTieg8MPGeFzbdfHyAA94mKzkd6", "effects": { "checkpoint": { "sequenceNumber": 3 @@ -142,7 +142,7 @@ Response: { } }, { - "digest": "DSidHVd7b7Thys1ehtjw9sDtGq34KiMKC3sTmg2ys5sX", + "digest": "CTghAa6p4x2gFzMkJV8b4TVeBbHtkGoXaeZ1Vzh3y5ut", "effects": { "checkpoint": { "sequenceNumber": 3 @@ -150,7 +150,7 @@ Response: { } }, { - "digest": "4LPxvoFmcA94gU2RuAmzhLP5QQZ8dyrMo8LVb8gmpVo1", + "digest": "87KM1JvWfHMoYiFeasoiLWPVL2PxBjTgYtuTf8Lk21CT", "effects": { "checkpoint": { "sequenceNumber": 3 @@ -158,7 +158,7 @@ Response: { } }, { - "digest": "7jpEY9PpZzHzDq7r9iBijzJuaLbCAKnSL6eujudmsSr4", + "digest": "FvRkrmggzayGPtrvGT6AGS8Jm7os61CCcG6N2BthoLQ3", "effects": { "checkpoint": { "sequenceNumber": 3 @@ -166,7 +166,7 @@ Response: { } }, { - "digest": "Cvni8txxPnGMqbECvskbzo3T2JKoenM8bUYSYRZnqrDt", + "digest": "86ABFdM2RxENvN1biiiUNv7T4nCayFkjELaz4MKwNguF", "effects": { "checkpoint": { "sequenceNumber": 3 @@ -191,7 +191,7 @@ Response: { }, "nodes": [ { - "digest": "Fpc7N9qYBCegSxBgmmEwANpQecoRmNriyNnA1WCgZ7T9", + "digest": "HN64Vz8PmNEztyXSjqgeC7BazCvvdHT9BN62t9WJJiiD", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -199,7 +199,7 @@ Response: { } }, { - "digest": "FirY733kBLzzbcnFsSPoeWLWAYBA1DcjHcurF9X1yxWa", + "digest": "14Dp55F4CcoMwSXo9UJJj9rLWHHrsh55u1bG8AyJzf29", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -207,7 +207,7 @@ Response: { } }, { - "digest": "9K2FJpFUUXiEV8LznzjUQJcY2K4vmX9kECwKas2vsyG", + "digest": "FSFfAaccXApG4NNDNwsvfeWqzZx7WHBtssn7yCpKF7w1", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -215,7 +215,7 @@ Response: { } }, { - "digest": "BwBbnCKP9UAtpPSVV3RZqzozM15AaHDFtoRnpqkWDBMk", + "digest": "432fq3xpYtMXxVMuNcBzPK4ikrpFTEVGEiKLNsjpmczY", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -223,7 +223,7 @@ Response: { } }, { - "digest": "9EdPgfA4esk9eiAHDGuhDSwznBpu4Z35cpEaaADvP5zT", + "digest": "oBvYm41RTyB7u5HGE91QdKNNRw5AYXBrFEDLJTXnN9F", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -231,7 +231,7 @@ Response: { } }, { - "digest": "CxwvRZkjcFEqnFeqT4zQyQwKRpaS1NMnfk6ZHgrcuWEQ", + "digest": "GQEae2TqUmShfWdHzyTieg8MPGeFzbdfHyAA94mKzkd6", "effects": { "checkpoint": { "sequenceNumber": 3 @@ -239,7 +239,7 @@ Response: { } }, { - "digest": "DSidHVd7b7Thys1ehtjw9sDtGq34KiMKC3sTmg2ys5sX", + "digest": "CTghAa6p4x2gFzMkJV8b4TVeBbHtkGoXaeZ1Vzh3y5ut", "effects": { "checkpoint": { "sequenceNumber": 3 @@ -247,7 +247,7 @@ Response: { } }, { - "digest": "4LPxvoFmcA94gU2RuAmzhLP5QQZ8dyrMo8LVb8gmpVo1", + "digest": "87KM1JvWfHMoYiFeasoiLWPVL2PxBjTgYtuTf8Lk21CT", "effects": { "checkpoint": { "sequenceNumber": 3 @@ -255,7 +255,7 @@ Response: { } }, { - "digest": "7jpEY9PpZzHzDq7r9iBijzJuaLbCAKnSL6eujudmsSr4", + "digest": "FvRkrmggzayGPtrvGT6AGS8Jm7os61CCcG6N2BthoLQ3", "effects": { "checkpoint": { "sequenceNumber": 3 @@ -263,7 +263,7 @@ Response: { } }, { - "digest": "Cvni8txxPnGMqbECvskbzo3T2JKoenM8bUYSYRZnqrDt", + "digest": "86ABFdM2RxENvN1biiiUNv7T4nCayFkjELaz4MKwNguF", "effects": { "checkpoint": { "sequenceNumber": 3 @@ -311,7 +311,7 @@ Response: { }, "nodes": [ { - "digest": "Fpc7N9qYBCegSxBgmmEwANpQecoRmNriyNnA1WCgZ7T9", + "digest": "HN64Vz8PmNEztyXSjqgeC7BazCvvdHT9BN62t9WJJiiD", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -319,7 +319,7 @@ Response: { } }, { - "digest": "FirY733kBLzzbcnFsSPoeWLWAYBA1DcjHcurF9X1yxWa", + "digest": "14Dp55F4CcoMwSXo9UJJj9rLWHHrsh55u1bG8AyJzf29", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -327,7 +327,7 @@ Response: { } }, { - "digest": "9K2FJpFUUXiEV8LznzjUQJcY2K4vmX9kECwKas2vsyG", + "digest": "FSFfAaccXApG4NNDNwsvfeWqzZx7WHBtssn7yCpKF7w1", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -335,7 +335,7 @@ Response: { } }, { - "digest": "BwBbnCKP9UAtpPSVV3RZqzozM15AaHDFtoRnpqkWDBMk", + "digest": "432fq3xpYtMXxVMuNcBzPK4ikrpFTEVGEiKLNsjpmczY", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -343,7 +343,7 @@ Response: { } }, { - "digest": "9EdPgfA4esk9eiAHDGuhDSwznBpu4Z35cpEaaADvP5zT", + "digest": "oBvYm41RTyB7u5HGE91QdKNNRw5AYXBrFEDLJTXnN9F", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -351,7 +351,7 @@ Response: { } }, { - "digest": "CxwvRZkjcFEqnFeqT4zQyQwKRpaS1NMnfk6ZHgrcuWEQ", + "digest": "GQEae2TqUmShfWdHzyTieg8MPGeFzbdfHyAA94mKzkd6", "effects": { "checkpoint": { "sequenceNumber": 3 @@ -359,7 +359,7 @@ Response: { } }, { - "digest": "DSidHVd7b7Thys1ehtjw9sDtGq34KiMKC3sTmg2ys5sX", + "digest": "CTghAa6p4x2gFzMkJV8b4TVeBbHtkGoXaeZ1Vzh3y5ut", "effects": { "checkpoint": { "sequenceNumber": 3 @@ -367,7 +367,7 @@ Response: { } }, { - "digest": "4LPxvoFmcA94gU2RuAmzhLP5QQZ8dyrMo8LVb8gmpVo1", + "digest": "87KM1JvWfHMoYiFeasoiLWPVL2PxBjTgYtuTf8Lk21CT", "effects": { "checkpoint": { "sequenceNumber": 3 @@ -375,7 +375,7 @@ Response: { } }, { - "digest": "7jpEY9PpZzHzDq7r9iBijzJuaLbCAKnSL6eujudmsSr4", + "digest": "FvRkrmggzayGPtrvGT6AGS8Jm7os61CCcG6N2BthoLQ3", "effects": { "checkpoint": { "sequenceNumber": 3 @@ -383,7 +383,7 @@ Response: { } }, { - "digest": "Cvni8txxPnGMqbECvskbzo3T2JKoenM8bUYSYRZnqrDt", + "digest": "86ABFdM2RxENvN1biiiUNv7T4nCayFkjELaz4MKwNguF", "effects": { "checkpoint": { "sequenceNumber": 3 @@ -431,7 +431,7 @@ Response: { }, "nodes": [ { - "digest": "Fpc7N9qYBCegSxBgmmEwANpQecoRmNriyNnA1WCgZ7T9", + "digest": "HN64Vz8PmNEztyXSjqgeC7BazCvvdHT9BN62t9WJJiiD", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -439,7 +439,7 @@ Response: { } }, { - "digest": "FirY733kBLzzbcnFsSPoeWLWAYBA1DcjHcurF9X1yxWa", + "digest": "14Dp55F4CcoMwSXo9UJJj9rLWHHrsh55u1bG8AyJzf29", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -447,7 +447,7 @@ Response: { } }, { - "digest": "9K2FJpFUUXiEV8LznzjUQJcY2K4vmX9kECwKas2vsyG", + "digest": "FSFfAaccXApG4NNDNwsvfeWqzZx7WHBtssn7yCpKF7w1", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -455,7 +455,7 @@ Response: { } }, { - "digest": "BwBbnCKP9UAtpPSVV3RZqzozM15AaHDFtoRnpqkWDBMk", + "digest": "432fq3xpYtMXxVMuNcBzPK4ikrpFTEVGEiKLNsjpmczY", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -463,7 +463,7 @@ Response: { } }, { - "digest": "9EdPgfA4esk9eiAHDGuhDSwznBpu4Z35cpEaaADvP5zT", + "digest": "oBvYm41RTyB7u5HGE91QdKNNRw5AYXBrFEDLJTXnN9F", "effects": { "checkpoint": { "sequenceNumber": 2 @@ -471,7 +471,7 @@ Response: { } }, { - "digest": "CxwvRZkjcFEqnFeqT4zQyQwKRpaS1NMnfk6ZHgrcuWEQ", + "digest": "GQEae2TqUmShfWdHzyTieg8MPGeFzbdfHyAA94mKzkd6", "effects": { "checkpoint": { "sequenceNumber": 3 @@ -479,7 +479,7 @@ Response: { } }, { - "digest": "DSidHVd7b7Thys1ehtjw9sDtGq34KiMKC3sTmg2ys5sX", + "digest": "CTghAa6p4x2gFzMkJV8b4TVeBbHtkGoXaeZ1Vzh3y5ut", "effects": { "checkpoint": { "sequenceNumber": 3 @@ -487,7 +487,7 @@ Response: { } }, { - "digest": "4LPxvoFmcA94gU2RuAmzhLP5QQZ8dyrMo8LVb8gmpVo1", + "digest": "87KM1JvWfHMoYiFeasoiLWPVL2PxBjTgYtuTf8Lk21CT", "effects": { "checkpoint": { "sequenceNumber": 3 @@ -495,7 +495,7 @@ Response: { } }, { - "digest": "7jpEY9PpZzHzDq7r9iBijzJuaLbCAKnSL6eujudmsSr4", + "digest": "FvRkrmggzayGPtrvGT6AGS8Jm7os61CCcG6N2BthoLQ3", "effects": { "checkpoint": { "sequenceNumber": 3 @@ -503,7 +503,7 @@ Response: { } }, { - "digest": "Cvni8txxPnGMqbECvskbzo3T2JKoenM8bUYSYRZnqrDt", + "digest": "86ABFdM2RxENvN1biiiUNv7T4nCayFkjELaz4MKwNguF", "effects": { "checkpoint": { "sequenceNumber": 3 @@ -592,7 +592,7 @@ Response: { { "cursor": "eyJjIjozLCJ0IjoyLCJpIjpmYWxzZX0", "node": { - "digest": "Fpc7N9qYBCegSxBgmmEwANpQecoRmNriyNnA1WCgZ7T9", + "digest": "HN64Vz8PmNEztyXSjqgeC7BazCvvdHT9BN62t9WJJiiD", "effects": { "checkpoint": { "sequenceNumber": 2 diff --git a/crates/iota-graphql-e2e-tests/tests/transactions/shared.exp b/crates/iota-graphql-e2e-tests/tests/transactions/shared.exp index e8499db5828..d14d150ad15 100644 --- a/crates/iota-graphql-e2e-tests/tests/transactions/shared.exp +++ b/crates/iota-graphql-e2e-tests/tests/transactions/shared.exp @@ -42,7 +42,7 @@ Response: { "transactions": { "nodes": [ { - "package": "0xc75e2a7ac0f53611d8d308f4c61cfd5eb0ebfe119fca77aa76725de93d04a2eb", + "package": "0x89e86c4735c8265305f0fa793bcec8bc0c62374c33035bcad3ba6eb8dffeedf1", "module": "m", "functionName": "get" } @@ -55,17 +55,17 @@ Response: { "nodes": [ { "__typename": "SharedObjectRead", - "address": "0xe2feed8adeb99f6cfbd36426e9cad756f2c083d56d51b9a8243c93389f514a04", + "address": "0x66fe37423f804cff0e56178a0cab944ca04c468d6a1f32cc003f380d3b97e5fe", "version": 2, - "digest": "Q6yqwPApQMm8cUXQpsnUmUCNR7taYTa5kNLHMeTH8f4", + "digest": "3xuze1PbHS7BukpEDvhHuB5vs9m1DmRve76xUaeN9M1t", "object": { "asMoveObject": { "contents": { "type": { - "repr": "0xc75e2a7ac0f53611d8d308f4c61cfd5eb0ebfe119fca77aa76725de93d04a2eb::m::Foo" + "repr": "0x89e86c4735c8265305f0fa793bcec8bc0c62374c33035bcad3ba6eb8dffeedf1::m::Foo" }, "json": { - "id": "0xe2feed8adeb99f6cfbd36426e9cad756f2c083d56d51b9a8243c93389f514a04", + "id": "0x66fe37423f804cff0e56178a0cab944ca04c468d6a1f32cc003f380d3b97e5fe", "x": "0" } } @@ -82,7 +82,7 @@ Response: { "transactions": { "nodes": [ { - "package": "0xc75e2a7ac0f53611d8d308f4c61cfd5eb0ebfe119fca77aa76725de93d04a2eb", + "package": "0x89e86c4735c8265305f0fa793bcec8bc0c62374c33035bcad3ba6eb8dffeedf1", "module": "m", "functionName": "inc" } @@ -102,12 +102,12 @@ Response: { "transactions": { "nodes": [ { - "package": "0xc75e2a7ac0f53611d8d308f4c61cfd5eb0ebfe119fca77aa76725de93d04a2eb", + "package": "0x89e86c4735c8265305f0fa793bcec8bc0c62374c33035bcad3ba6eb8dffeedf1", "module": "m", "functionName": "get" }, { - "package": "0xc75e2a7ac0f53611d8d308f4c61cfd5eb0ebfe119fca77aa76725de93d04a2eb", + "package": "0x89e86c4735c8265305f0fa793bcec8bc0c62374c33035bcad3ba6eb8dffeedf1", "module": "m", "functionName": "inc" } diff --git a/crates/iota-graphql-e2e-tests/tests/transactions/system.exp b/crates/iota-graphql-e2e-tests/tests/transactions/system.exp index 6056ad4c2da..02fd27d573e 100644 --- a/crates/iota-graphql-e2e-tests/tests/transactions/system.exp +++ b/crates/iota-graphql-e2e-tests/tests/transactions/system.exp @@ -7,7 +7,7 @@ Response: { "transactionBlocks": { "nodes": [ { - "digest": "Cpgs1hPAQs2nfbQkD2ZsEfEAvmtTjb7QT5mtXaMQwhgD", + "digest": "3i3tgknuHtmwGpo2ybxbvVmBUsTWpaaWvKxbEKzc279Q", "sender": null, "signatures": [ "AAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAAA==" @@ -407,7 +407,7 @@ Response: { "json": { "id": "0x0000000000000000000000000000000000000000000000000000000000000008", "inner": { - "id": "0x0a4818932295cdda8e2bf2bdf2af0d8022da23aafcc2a3a671f0db8a18a40914", + "id": "0x3ea5f6c162a25be99c5853e0d393a986af600b290c1c48ce6896602d36115385", "version": "1" } } @@ -489,7 +489,7 @@ Response: { "json": { "id": "0x0000000000000000000000000000000000000000000000000000000000000403", "lists": { - "id": "0x60dbd7095109dfd525da2db8f525d33227ba04ae8d25d8709a507018f52d31c0", + "id": "0x68c6e7ce3c1cc8d9740b644a374a43ab37106afa81f5f863abbea3128d3be410", "size": "0" } } @@ -586,17 +586,51 @@ Response: { { "cursor": "eyJpIjo5LCJjIjowfQ", "node": { - "address": "0x17c0381ca02ae48b3a0819b083e43663e17be2e3936fbf06aad42e97c3065a08", + "address": "0x4209edfee0c6722b4b85e7a15111755c97bc1a8fba7977645cbfa07792b077a3", "asMoveObject": { "contents": { "type": { - "repr": "0x0000000000000000000000000000000000000000000000000000000000000002::coin::Coin<0x0000000000000000000000000000000000000000000000000000000000000002::iota::IOTA>" + "repr": "0x0000000000000000000000000000000000000000000000000000000000000002::display::Display<0x000000000000000000000000000000000000000000000000000000000000107a::nft::Nft>" }, "json": { - "id": "0x17c0381ca02ae48b3a0819b083e43663e17be2e3936fbf06aad42e97c3065a08", - "balance": { - "value": "30000000000000000" - } + "id": "0x4209edfee0c6722b4b85e7a15111755c97bc1a8fba7977645cbfa07792b077a3", + "fields": { + "contents": [ + { + "key": "name", + "value": "{immutable_metadata.name}" + }, + { + "key": "image_url", + "value": "{immutable_metadata.uri}" + }, + { + "key": "description", + "value": "{immutable_metadata.description}" + }, + { + "key": "creator", + "value": "{immutable_metadata.issuer_name}" + }, + { + "key": "version", + "value": "{immutable_metadata.version}" + }, + { + "key": "media_type", + "value": "{immutable_metadata.media_type}" + }, + { + "key": "collection_name", + "value": "{immutable_metadata.collection_name}" + }, + { + "key": "immutable_issuer", + "value": "{immutable_issuer}" + } + ] + }, + "version": 1 } } }, @@ -605,30 +639,6 @@ Response: { }, { "cursor": "eyJpIjoxMCwiYyI6MH0", - "node": { - "address": "0x3017347a061e7145034c803925f9a84e7e2fc1a24f09d1701996d9fb66a970f2", - "asMoveObject": { - "contents": { - "type": { - "repr": "0x0000000000000000000000000000000000000000000000000000000000000002::dynamic_field::Field" - }, - "json": { - "id": "0x3017347a061e7145034c803925f9a84e7e2fc1a24f09d1701996d9fb66a970f2", - "name": "1", - "value": { - "version": "1", - "epoch": "0", - "randomness_round": "0", - "random_bytes": [] - } - } - } - }, - "asMovePackage": null - } - }, - { - "cursor": "eyJpIjoxMSwiYyI6MH0", "node": { "address": "0x5a6383eb592bab4ff7c037a2118c514149ba9a86cf5a3b019c7034686365183f", "asMoveObject": { @@ -665,6 +675,24 @@ Response: { "asMovePackage": null } }, + { + "cursor": "eyJpIjoxMSwiYyI6MH0", + "node": { + "address": "0x5d2928d23a808841308e3097bf834a2326f98a9bc147c7cf2df7506ff80e641a", + "asMoveObject": { + "contents": { + "type": { + "repr": "0x0000000000000000000000000000000000000000000000000000000000000003::validator_cap::UnverifiedValidatorOperationCap" + }, + "json": { + "id": "0x5d2928d23a808841308e3097bf834a2326f98a9bc147c7cf2df7506ff80e641a", + "authorizer_validator_address": "0x28f02a953f3553f51a9365593c7d4bd0643d2085f004b18c6ca9de51682b2c80" + } + } + }, + "asMovePackage": null + } + }, { "cursor": "eyJpIjoxMiwiYyI6MH0", "node": { @@ -672,7 +700,7 @@ Response: { "asMoveObject": { "contents": { "type": { - "repr": "0x0000000000000000000000000000000000000000000000000000000000000002::dynamic_field::Field" + "repr": "0x0000000000000000000000000000000000000000000000000000000000000002::dynamic_field::Field" }, "json": { "id": "0x6af2a2b7ca60bf76174adfd3e9c4957f8e937759603182f9b46c7f6c5f19c6d2", @@ -683,7 +711,7 @@ Response: { "system_state_version": "1", "iota_treasury_cap": { "inner": { - "id": "0xde341860ab0f8249d38c7924fa287bdd20ac5dacb26a276b53a875a2be9972a4", + "id": "0xccac92582a6d7c09456cc24b9c75416411abd4b02a1bfceda7f521aa439e3a8d", "total_supply": { "value": "31800000000000000" } @@ -930,15 +958,15 @@ Response: { "next_epoch_p2p_address": null, "next_epoch_primary_address": null, "extra_fields": { - "id": "0x00805e85ca185f935cb7248b58bac2528ec7457ef1b10baf8ef03d9a237d46e4", + "id": "0xdc02ba5b963a4abfa19d98d5fa26b403e524459578a26a38ba34fae89fd2b66c", "size": "0" } }, "voting_power": "10000", - "operation_cap_id": "0xcf955500c82314d83e8abfeb712e306c5acccfc8b77b754b0e9bd8f921b9da43", + "operation_cap_id": "0x5d2928d23a808841308e3097bf834a2326f98a9bc147c7cf2df7506ff80e641a", "gas_price": "1000", "staking_pool": { - "id": "0x37e12b05c5ead707489d81b4fa16d6ce0031fb7a55dd22ba7855fa621b2aeea0", + "id": "0x73877815d01eb79ccc8d3936b33dd91c9776b70a9a972a245dd0348278dd34fe", "activation_epoch": "0", "deactivation_epoch": null, "iota_balance": "1500000000000000", @@ -947,14 +975,14 @@ Response: { }, "pool_token_balance": "1500000000000000", "exchange_rates": { - "id": "0x08e7a0374786bdb308e5b6f3d0ff0147f9ee5bc9de1272c52db9eadb75b4575c", + "id": "0xb9b7eef578fca16ef4a12c18c5c2ba34e02456c143e1200a77b3ed4343542cce", "size": "1" }, "pending_stake": "0", "pending_total_iota_withdraw": "0", "pending_pool_token_withdraw": "0", "extra_fields": { - "id": "0xd42abafef5e951452dec95b36dfe8e14510e15645f6c47c47efa5208c34b3f82", + "id": "0xd77de5a6f0cd42d4af49f6e1026fac1d903bdec27b7d7db1655d4bae7fc0da91", "size": "0" } }, @@ -963,35 +991,35 @@ Response: { "next_epoch_gas_price": "1000", "next_epoch_commission_rate": "200", "extra_fields": { - "id": "0x2bd3bc51297bd1883a039d0bec2cb160519df1a2cb4b228a1127e7e93fdf9746", + "id": "0xe39145cecdb319f4011b183f128d6c1ea7297e1368b585fe153725e5cda8a3cf", "size": "0" } } ], "pending_active_validators": { "contents": { - "id": "0x76cf61f73bf4d578aaafe61a3cb91654e64880da7a4ecbbf82c955df78345308", + "id": "0x74f4b1b3b2e4743f69de0d1f1c70c2dd93148306666afc9b72bdcc15b35c219f", "size": "0" } }, "pending_removals": [], "staking_pool_mappings": { - "id": "0xa8ddddc49351578fdd00675f868dba2ede333982acd3ce615c6e5387709ee5e2", + "id": "0x915b7f830ca364410ce070137b5b9fe609ac5a7d08320090484bec44110c42a1", "size": "1" }, "inactive_validators": { - "id": "0x529312e17eba8de6ec856216eb76f9a69ed9397511d4e51941c2a55b7d5f223b", + "id": "0xcf0642d199c09a72bad034a642765769a95a7c146fd026a9edf8a63fa7b223b1", "size": "0" }, "validator_candidates": { - "id": "0x7a241a22465736e41d283817bea8d8775f887ad91a7ae893a129c22d660a4ab6", + "id": "0x67ff1104032b479598188affaf00529afbcdd1b1e90ce583020c6bfab657b4a9", "size": "0" }, "at_risk_validators": { "contents": [] }, "extra_fields": { - "id": "0x2275e20fa9aa92c01701edc97925b0c2cdfcc57d1da108087b1c7f25b700c7a4", + "id": "0x5abbfe1fc28887ee84063b633ed935d4020dda7c660c3eea33fd7322146766a7", "size": "0" } }, @@ -1005,13 +1033,14 @@ Response: { }, "parameters": { "epoch_duration_ms": "86400000", + "min_validator_count": "4", "max_validator_count": "150", "min_validator_joining_stake": "2000000000000000", "validator_low_stake_threshold": "1500000000000000", "validator_very_low_stake_threshold": "1000000000000000", "validator_low_stake_grace_period": "7", "extra_fields": { - "id": "0x98fda9947bae7fd10900d9b916e94e08699cf7bc4a7f099ba1f3836926278fab", + "id": "0x3198c51012892833039e0c4bc592c2f965d592d6a8d762564cbf3011b3478a2d", "size": "0" } }, @@ -1030,7 +1059,7 @@ Response: { "safe_mode_non_refundable_storage_fee": "0", "epoch_start_timestamp_ms": "0", "extra_fields": { - "id": "0xb96b62cd4f66eb8a3c32f8ffa29697b8d4a1209f7fa9c9aaf01947b2ebb92a1d", + "id": "0xb5a0ba748635636e6234143857cd292ede2d029680d5d31e85edf6b07dd642d2", "size": "0" } } @@ -1043,51 +1072,19 @@ Response: { { "cursor": "eyJpIjoxMywiYyI6MH0", "node": { - "address": "0x7e41c686d7c309827999e66c7cbaabfe1e7428458dab9f7e93dc1abbb6c64157", + "address": "0x6e7a627fd970b3b88fca49b258fd01ee48509b2b9a35a6d2fc496d62b7feff44", "asMoveObject": { "contents": { "type": { - "repr": "0x0000000000000000000000000000000000000000000000000000000000000002::display::Display<0x000000000000000000000000000000000000000000000000000000000000107a::nft::Nft>" + "repr": "0x0000000000000000000000000000000000000000000000000000000000000002::dynamic_field::Field" }, "json": { - "id": "0x7e41c686d7c309827999e66c7cbaabfe1e7428458dab9f7e93dc1abbb6c64157", - "fields": { - "contents": [ - { - "key": "name", - "value": "{immutable_metadata.name}" - }, - { - "key": "image_url", - "value": "{immutable_metadata.uri}" - }, - { - "key": "description", - "value": "{immutable_metadata.description}" - }, - { - "key": "creator", - "value": "{immutable_metadata.issuer_name}" - }, - { - "key": "version", - "value": "{immutable_metadata.version}" - }, - { - "key": "media_type", - "value": "{immutable_metadata.media_type}" - }, - { - "key": "collection_name", - "value": "{immutable_metadata.collection_name}" - }, - { - "key": "immutable_issuer", - "value": "{immutable_issuer}" - } - ] - }, - "version": 1 + "id": "0x6e7a627fd970b3b88fca49b258fd01ee48509b2b9a35a6d2fc496d62b7feff44", + "name": "0", + "value": { + "iota_amount": "0", + "pool_token_amount": "0" + } } } }, @@ -1097,15 +1094,15 @@ Response: { { "cursor": "eyJpIjoxNCwiYyI6MH0", "node": { - "address": "0xc1ea833a9381cdb3d00f7eb3c38b0603c94814031257a74bbfa0148ec788f881", + "address": "0x9c800dae0d735e34c71f729420132d502854f801f4585606f03455e375f1bc69", "asMoveObject": { "contents": { "type": { "repr": "0x0000000000000000000000000000000000000000000000000000000000000002::dynamic_field::Field<0x0000000000000000000000000000000000000000000000000000000000000002::object::ID,address>" }, "json": { - "id": "0xc1ea833a9381cdb3d00f7eb3c38b0603c94814031257a74bbfa0148ec788f881", - "name": "0x37e12b05c5ead707489d81b4fa16d6ce0031fb7a55dd22ba7855fa621b2aeea0", + "id": "0x9c800dae0d735e34c71f729420132d502854f801f4585606f03455e375f1bc69", + "name": "0x73877815d01eb79ccc8d3936b33dd91c9776b70a9a972a245dd0348278dd34fe", "value": "0x28f02a953f3553f51a9365593c7d4bd0643d2085f004b18c6ca9de51682b2c80" } } @@ -1116,16 +1113,20 @@ Response: { { "cursor": "eyJpIjoxNSwiYyI6MH0", "node": { - "address": "0xc22d782d6b686022721c7a680612c20817b6cad04210f7df35e471dfd78881f8", + "address": "0x9ce49a5c6edce2595528dd97fe8cbd53138a8dbee20810d941a396bfb915b9f9", "asMoveObject": { "contents": { "type": { - "repr": "0x0000000000000000000000000000000000000000000000000000000000000002::coin::Coin<0x0000000000000000000000000000000000000000000000000000000000000002::iota::IOTA>" + "repr": "0x0000000000000000000000000000000000000000000000000000000000000002::dynamic_field::Field" }, "json": { - "id": "0xc22d782d6b686022721c7a680612c20817b6cad04210f7df35e471dfd78881f8", - "balance": { - "value": "300000000000000" + "id": "0x9ce49a5c6edce2595528dd97fe8cbd53138a8dbee20810d941a396bfb915b9f9", + "name": "1", + "value": { + "version": "1", + "epoch": "0", + "randomness_round": "0", + "random_bytes": [] } } } @@ -1136,18 +1137,16 @@ Response: { { "cursor": "eyJpIjoxNiwiYyI6MH0", "node": { - "address": "0xc39644d3d20f6965de0f07b7fd8a02a283f87b04a3401668f3c87c57208c253c", + "address": "0xa6544a66698c9baad5259e89ee9858db835ed8f099bc032fbfcb1f73e8377ae8", "asMoveObject": { "contents": { "type": { - "repr": "0x0000000000000000000000000000000000000000000000000000000000000003::staking_pool::StakedIota" + "repr": "0x0000000000000000000000000000000000000000000000000000000000000002::coin::Coin<0x0000000000000000000000000000000000000000000000000000000000000002::iota::IOTA>" }, "json": { - "id": "0xc39644d3d20f6965de0f07b7fd8a02a283f87b04a3401668f3c87c57208c253c", - "pool_id": "0x37e12b05c5ead707489d81b4fa16d6ce0031fb7a55dd22ba7855fa621b2aeea0", - "stake_activation_epoch": "0", - "principal": { - "value": "1500000000000000" + "id": "0xa6544a66698c9baad5259e89ee9858db835ed8f099bc032fbfcb1f73e8377ae8", + "balance": { + "value": "300000000000000" } } } @@ -1158,18 +1157,16 @@ Response: { { "cursor": "eyJpIjoxNywiYyI6MH0", "node": { - "address": "0xcc39f8b8e9648f8bf95a9782944f86b4eadb45f965da8fadcc27c99968d905d1", + "address": "0xab8b65fa8ccce42a31f28133855ce3e84f5bf316b15b8177c1a81a0b3c524faa", "asMoveObject": { "contents": { "type": { - "repr": "0x0000000000000000000000000000000000000000000000000000000000000002::dynamic_field::Field" + "repr": "0x0000000000000000000000000000000000000000000000000000000000000002::coin::Coin<0x0000000000000000000000000000000000000000000000000000000000000002::iota::IOTA>" }, "json": { - "id": "0xcc39f8b8e9648f8bf95a9782944f86b4eadb45f965da8fadcc27c99968d905d1", - "name": "0", - "value": { - "iota_amount": "0", - "pool_token_amount": "0" + "id": "0xab8b65fa8ccce42a31f28133855ce3e84f5bf316b15b8177c1a81a0b3c524faa", + "balance": { + "value": "30000000000000000" } } } @@ -1180,15 +1177,19 @@ Response: { { "cursor": "eyJpIjoxOCwiYyI6MH0", "node": { - "address": "0xcf955500c82314d83e8abfeb712e306c5acccfc8b77b754b0e9bd8f921b9da43", + "address": "0xaf0555cf30fe85c731be9c7feac04bd88ceab245d36fc6952ce1c7ad662e032b", "asMoveObject": { "contents": { "type": { - "repr": "0x0000000000000000000000000000000000000000000000000000000000000003::validator_cap::UnverifiedValidatorOperationCap" + "repr": "0x0000000000000000000000000000000000000000000000000000000000000003::staking_pool::StakedIota" }, "json": { - "id": "0xcf955500c82314d83e8abfeb712e306c5acccfc8b77b754b0e9bd8f921b9da43", - "authorizer_validator_address": "0x28f02a953f3553f51a9365593c7d4bd0643d2085f004b18c6ca9de51682b2c80" + "id": "0xaf0555cf30fe85c731be9c7feac04bd88ceab245d36fc6952ce1c7ad662e032b", + "pool_id": "0x73877815d01eb79ccc8d3936b33dd91c9776b70a9a972a245dd0348278dd34fe", + "stake_activation_epoch": "0", + "principal": { + "value": "1500000000000000" + } } } }, @@ -1198,14 +1199,14 @@ Response: { { "cursor": "eyJpIjoxOSwiYyI6MH0", "node": { - "address": "0xe6ad211c1ac09d032251d184db0824f16ad0de8b858bff0e046fde919a88c08b", + "address": "0xc04784618c2abcf1a672b8eed0b32b0c82399a1949449fa1780894d96947112c", "asMoveObject": { "contents": { "type": { "repr": "0x0000000000000000000000000000000000000000000000000000000000000002::coin::CoinMetadata<0x0000000000000000000000000000000000000000000000000000000000000002::iota::IOTA>" }, "json": { - "id": "0xe6ad211c1ac09d032251d184db0824f16ad0de8b858bff0e046fde919a88c08b", + "id": "0xc04784618c2abcf1a672b8eed0b32b0c82399a1949449fa1780894d96947112c", "decimals": 9, "name": "IOTA", "symbol": "IOTA", @@ -1259,7 +1260,7 @@ Response: { "idDeleted": false, "outputState": { "address": "0x0000000000000000000000000000000000000000000000000000000000000001", - "digest": "7AUMJwqfXbAV3GZbGjPeBK6NCUXxMxxUz62TS6MjhMY3" + "digest": "H5sXqQ1xWAnDFG5s5jAXvhJcjwPamEaEMWPrZ85BqohT" } }, { @@ -1268,7 +1269,7 @@ Response: { "idDeleted": false, "outputState": { "address": "0x0000000000000000000000000000000000000000000000000000000000000002", - "digest": "HpTrU3csg7qRB1TcgBzeW2WYofPQD1ySZYhLawsdQNZ3" + "digest": "CtqfTgZVZ4ZnQzZHKg7aBVrCWDdQKTHQhadcd2XmdA9y" } }, { @@ -1277,7 +1278,7 @@ Response: { "idDeleted": false, "outputState": { "address": "0x0000000000000000000000000000000000000000000000000000000000000003", - "digest": "4mnkQWk7TkeTQb2WpD3cJekf9W6Nyd1SJKoC4FeDGzxN" + "digest": "DaBy9yCgTn37Ppv4fikHLqPdqV8F7kJf7URfxCtF2e9j" } }, { @@ -1286,7 +1287,7 @@ Response: { "idDeleted": false, "outputState": { "address": "0x0000000000000000000000000000000000000000000000000000000000000005", - "digest": "81HKA2Xi48k1v9QnhvgAXDxT7kVE2S39XyiNYH48kVWw" + "digest": "2V6tZ9pU4S3NsRdULriF7GydGmp457uSo2ty4ymB8VXY" } }, { @@ -1295,7 +1296,7 @@ Response: { "idDeleted": false, "outputState": { "address": "0x0000000000000000000000000000000000000000000000000000000000000006", - "digest": "3RsTZi66r7dDbcgMMQS8oxFcAbpEnfS61Piehj7peK8p" + "digest": "GqqdRNHyEjeByAbjVkot27KpXPiaJEWZem6dnK2x5rV7" } }, { @@ -1304,7 +1305,7 @@ Response: { "idDeleted": false, "outputState": { "address": "0x0000000000000000000000000000000000000000000000000000000000000008", - "digest": "FKGW6NDeitr9gStJ58iCZjf3yrSNLKaRTkNKgtAsCYm6" + "digest": "GxD19fC6Py3PdLE53C5QXaHgnabfWSnMcmasRjreF5RY" } }, { @@ -1313,7 +1314,7 @@ Response: { "idDeleted": false, "outputState": { "address": "0x000000000000000000000000000000000000000000000000000000000000000b", - "digest": "C1nWqcKgwnjhZbi72fNL7cxE7CNGmrHR3KgZzs8a2V9h" + "digest": "6wVDVa1i8WYteTiiE3bPziuY56LBv7Pwc4ji8bqWT7aN" } }, { @@ -1322,7 +1323,7 @@ Response: { "idDeleted": false, "outputState": { "address": "0x0000000000000000000000000000000000000000000000000000000000000403", - "digest": "3oJWhcHhvgF3jCztsz9SCmPe7RpH5obzzqQVvwF7x5bg" + "digest": "65TQgghKFiqF7tVcNmkH9TWYzN97WztTBSSsp4WvPrrw" } }, { @@ -1331,34 +1332,34 @@ Response: { "idDeleted": false, "outputState": { "address": "0x000000000000000000000000000000000000000000000000000000000000107a", - "digest": "vVxaoTtVnsooFc5CejECwfwQJAiqYAzF83VLw6zEdyL" + "digest": "67XCsKueapC65naS4Lq7a9a8WkzoKEmzWGsYz9vAenzc" } }, { - "address": "0x17c0381ca02ae48b3a0819b083e43663e17be2e3936fbf06aad42e97c3065a08", + "address": "0x4209edfee0c6722b4b85e7a15111755c97bc1a8fba7977645cbfa07792b077a3", "idCreated": true, "idDeleted": false, "outputState": { - "address": "0x17c0381ca02ae48b3a0819b083e43663e17be2e3936fbf06aad42e97c3065a08", - "digest": "CU68h6AHL2gKsmGFagWeVudqNE2Qx5UdXVKfcKn8tSZm" + "address": "0x4209edfee0c6722b4b85e7a15111755c97bc1a8fba7977645cbfa07792b077a3", + "digest": "FeZa7xVC7qyZFN8GXCtJXXSyesfFBC5AUjF2dAHePsnr" } }, { - "address": "0x3017347a061e7145034c803925f9a84e7e2fc1a24f09d1701996d9fb66a970f2", + "address": "0x5a6383eb592bab4ff7c037a2118c514149ba9a86cf5a3b019c7034686365183f", "idCreated": true, "idDeleted": false, "outputState": { - "address": "0x3017347a061e7145034c803925f9a84e7e2fc1a24f09d1701996d9fb66a970f2", - "digest": "J59wYRtmpiePR5UDoTV8kaBRh5CrhpGdNF2DT3k6GEv6" + "address": "0x5a6383eb592bab4ff7c037a2118c514149ba9a86cf5a3b019c7034686365183f", + "digest": "89TEkZDyktBqQQM3ZGZUAKJX6NetVgcY1yzdro4WopPg" } }, { - "address": "0x5a6383eb592bab4ff7c037a2118c514149ba9a86cf5a3b019c7034686365183f", + "address": "0x5d2928d23a808841308e3097bf834a2326f98a9bc147c7cf2df7506ff80e641a", "idCreated": true, "idDeleted": false, "outputState": { - "address": "0x5a6383eb592bab4ff7c037a2118c514149ba9a86cf5a3b019c7034686365183f", - "digest": "Eo6p1RYX5B1WoBPTQUfCkYCn5q7FySXmcKsSktiGyVXf" + "address": "0x5d2928d23a808841308e3097bf834a2326f98a9bc147c7cf2df7506ff80e641a", + "digest": "8UAy9EsUau2MkqGAPHDgvf8yzPJzPD21yx8LSgFpuu8N" } }, { @@ -1367,70 +1368,70 @@ Response: { "idDeleted": false, "outputState": { "address": "0x6af2a2b7ca60bf76174adfd3e9c4957f8e937759603182f9b46c7f6c5f19c6d2", - "digest": "FZgiUDrLxJ1AkaefGfkYnoJwj2vqeLQYVotu3F4yKvTz" + "digest": "3NNP2MZAhHjVhW6FUkczN9FjkBgoMFb3D3aBoqrzFaWW" } }, { - "address": "0x7e41c686d7c309827999e66c7cbaabfe1e7428458dab9f7e93dc1abbb6c64157", + "address": "0x6e7a627fd970b3b88fca49b258fd01ee48509b2b9a35a6d2fc496d62b7feff44", "idCreated": true, "idDeleted": false, "outputState": { - "address": "0x7e41c686d7c309827999e66c7cbaabfe1e7428458dab9f7e93dc1abbb6c64157", - "digest": "9ufGyP4K6jwDAoqdrnVoXzBa1gabT9W1kiqcM8WaUrzQ" + "address": "0x6e7a627fd970b3b88fca49b258fd01ee48509b2b9a35a6d2fc496d62b7feff44", + "digest": "JBCMmBnr6HvySXPCx3tgUYfAe64poHAD9NzMDW2MAw1s" } }, { - "address": "0xc1ea833a9381cdb3d00f7eb3c38b0603c94814031257a74bbfa0148ec788f881", + "address": "0x9c800dae0d735e34c71f729420132d502854f801f4585606f03455e375f1bc69", "idCreated": true, "idDeleted": false, "outputState": { - "address": "0xc1ea833a9381cdb3d00f7eb3c38b0603c94814031257a74bbfa0148ec788f881", - "digest": "HPavCU471E8BQrDKenuuajjrRxsvPfr17szocdA8sTqw" + "address": "0x9c800dae0d735e34c71f729420132d502854f801f4585606f03455e375f1bc69", + "digest": "Cg7vTwxEaCQykuxHDhTWU2T1TMP2xa8fKnEM4vJ3XL1z" } }, { - "address": "0xc22d782d6b686022721c7a680612c20817b6cad04210f7df35e471dfd78881f8", + "address": "0x9ce49a5c6edce2595528dd97fe8cbd53138a8dbee20810d941a396bfb915b9f9", "idCreated": true, "idDeleted": false, "outputState": { - "address": "0xc22d782d6b686022721c7a680612c20817b6cad04210f7df35e471dfd78881f8", - "digest": "CGonGq6ZmRevWZGyfQHiZiitHu3zFaj1NeB8QVZXKCuC" + "address": "0x9ce49a5c6edce2595528dd97fe8cbd53138a8dbee20810d941a396bfb915b9f9", + "digest": "Fe5D4zYiUR4u9uYB9cAWXr2HRSV92bL3BUAw2vA8SH33" } }, { - "address": "0xc39644d3d20f6965de0f07b7fd8a02a283f87b04a3401668f3c87c57208c253c", + "address": "0xa6544a66698c9baad5259e89ee9858db835ed8f099bc032fbfcb1f73e8377ae8", "idCreated": true, "idDeleted": false, "outputState": { - "address": "0xc39644d3d20f6965de0f07b7fd8a02a283f87b04a3401668f3c87c57208c253c", - "digest": "7WAP6vZLa2BKZKUo4VJtePxN7Q5HHza9hvN9CZTPN8mV" + "address": "0xa6544a66698c9baad5259e89ee9858db835ed8f099bc032fbfcb1f73e8377ae8", + "digest": "8DSGgS8szoRftGiFFtdqgWNB2XmaF6qtczRKgj1Zkenn" } }, { - "address": "0xcc39f8b8e9648f8bf95a9782944f86b4eadb45f965da8fadcc27c99968d905d1", + "address": "0xab8b65fa8ccce42a31f28133855ce3e84f5bf316b15b8177c1a81a0b3c524faa", "idCreated": true, "idDeleted": false, "outputState": { - "address": "0xcc39f8b8e9648f8bf95a9782944f86b4eadb45f965da8fadcc27c99968d905d1", - "digest": "GndbqhHuzKrEnUBmG84cZipkv5pELF22QyN6jLecQYMp" + "address": "0xab8b65fa8ccce42a31f28133855ce3e84f5bf316b15b8177c1a81a0b3c524faa", + "digest": "Gaf625KrgvnGquoHpLnu9V4PxCPLrXjaPAj6TNUoAi9i" } }, { - "address": "0xcf955500c82314d83e8abfeb712e306c5acccfc8b77b754b0e9bd8f921b9da43", + "address": "0xaf0555cf30fe85c731be9c7feac04bd88ceab245d36fc6952ce1c7ad662e032b", "idCreated": true, "idDeleted": false, "outputState": { - "address": "0xcf955500c82314d83e8abfeb712e306c5acccfc8b77b754b0e9bd8f921b9da43", - "digest": "DjtuAynxT1S1qNbkD8Q3WWQ5qQFa7yQt8LY2b92SrSh2" + "address": "0xaf0555cf30fe85c731be9c7feac04bd88ceab245d36fc6952ce1c7ad662e032b", + "digest": "FW486vMb4Q85vApfnZqm85zay37DDwMq5xpJnEQrduo3" } }, { - "address": "0xe6ad211c1ac09d032251d184db0824f16ad0de8b858bff0e046fde919a88c08b", + "address": "0xc04784618c2abcf1a672b8eed0b32b0c82399a1949449fa1780894d96947112c", "idCreated": true, "idDeleted": false, "outputState": { - "address": "0xe6ad211c1ac09d032251d184db0824f16ad0de8b858bff0e046fde919a88c08b", - "digest": "ANXdBfsXeJLMBjj7e5KHjFibA682VkZeZiPVF4BqKi2u" + "address": "0xc04784618c2abcf1a672b8eed0b32b0c82399a1949449fa1780894d96947112c", + "digest": "DygRNA82cC3hz4NnVnneEWu1VVkCbbVdspUJq8renRpv" } } ] @@ -1452,7 +1453,7 @@ Response: { "sequenceNumber": 0 }, "transactionBlock": { - "digest": "Cpgs1hPAQs2nfbQkD2ZsEfEAvmtTjb7QT5mtXaMQwhgD" + "digest": "3i3tgknuHtmwGpo2ybxbvVmBUsTWpaaWvKxbEKzc279Q" } }, "expiration": null @@ -1504,7 +1505,7 @@ Response: { "dependencies": { "nodes": [ { - "digest": "Cpgs1hPAQs2nfbQkD2ZsEfEAvmtTjb7QT5mtXaMQwhgD" + "digest": "3i3tgknuHtmwGpo2ybxbvVmBUsTWpaaWvKxbEKzc279Q" } ] }, @@ -1604,7 +1605,7 @@ Response: { "dependencies": { "nodes": [ { - "digest": "Cpgs1hPAQs2nfbQkD2ZsEfEAvmtTjb7QT5mtXaMQwhgD" + "digest": "3i3tgknuHtmwGpo2ybxbvVmBUsTWpaaWvKxbEKzc279Q" } ] }, @@ -1619,7 +1620,7 @@ Response: { "idDeleted": false, "outputState": { "address": "0x0000000000000000000000000000000000000000000000000000000000000005", - "digest": "CGyGKFu385GVbKPD57rNrb1fPoLg1G3trazCFvfNWFXF" + "digest": "Do9BxST2vAmc7ZRsxohXXg5S3QLzmgUYYQnP2ejXtP93" } }, { @@ -1628,31 +1629,25 @@ Response: { "idDeleted": false, "outputState": { "address": "0x4509fa198370254af0418248c9718bb206e810e1bce9fc8ffd0c500aef972f4d", - "digest": "5eggD92os4DP51u7VHtJppCaPUwWZ7TLkWBJ5j5FJ23r" + "digest": "BSa7PKAWVFZob5cE6nN1JWtoG5v45m2w8WVTQ8SxMxeY" } }, { - "address": "0x5b890eaf2abcfa2ab90b77b8e6f3d5d8609586c3e583baf3dccd5af17edf48d1", + "address": "0x68eb1d10bdcf35211aafe684fe3568824238bdee9ec5e350c69990bb6d2d8c1d", "idCreated": true, "idDeleted": false, "outputState": { - "address": "0x5b890eaf2abcfa2ab90b77b8e6f3d5d8609586c3e583baf3dccd5af17edf48d1", - "digest": "ARKR7Cs2VVxPWp8x97Wn9PKSpKSv6GktUezxyfpAeGay" + "address": "0x68eb1d10bdcf35211aafe684fe3568824238bdee9ec5e350c69990bb6d2d8c1d", + "digest": "FZvmYvoCZAtb7pk1EDNGMzN7rFiSRGu9zrYnYFZVMRJm" } }, { "address": "0x6af2a2b7ca60bf76174adfd3e9c4957f8e937759603182f9b46c7f6c5f19c6d2", "idCreated": false, - "idDeleted": true, - "outputState": null - }, - { - "address": "0x7d8c6c48df3647d66b321d7cd97635b53d8dcc6b1c4253b3f90a0d0875eca7bf", - "idCreated": true, "idDeleted": false, "outputState": { - "address": "0x7d8c6c48df3647d66b321d7cd97635b53d8dcc6b1c4253b3f90a0d0875eca7bf", - "digest": "DAdadQkCUYJUSXVnVzAtcHg91AVYQf3ofKqZMSZrcqNz" + "address": "0x6af2a2b7ca60bf76174adfd3e9c4957f8e937759603182f9b46c7f6c5f19c6d2", + "digest": "33Bg8QUCxGNcSJ5xCZ1wVEWrFomUAyANogxuJYvnKjAB" } } ] diff --git a/crates/iota-graphql-rpc/schema.graphql b/crates/iota-graphql-rpc/schema.graphql index fba63a69734..be787e02e22 100644 --- a/crates/iota-graphql-rpc/schema.graphql +++ b/crates/iota-graphql-rpc/schema.graphql @@ -191,7 +191,7 @@ type AuthenticatorStateExpireTransaction { """ minEpoch: Epoch """ - The initial version that the AuthenticatorStateUpdate was shared at. + The initial version that the AuthenticatorStateUpdateV1 was shared at. """ authenticatorObjInitialSharedVersion: UInt53! } @@ -4400,7 +4400,7 @@ type Validator { """ stakingPool: MoveObject @deprecated(reason: "The staking pool is a wrapped object. Access its fields directly on the `Validator` type.") """ - The ID of this validator's `0x3::staking_pool::StakingPool`. + The ID of this validator's `0x3::staking_pool::StakingPoolV1`. """ stakingPoolId: IotaAddress! """ diff --git a/crates/iota-graphql-rpc/src/types/transaction_block_kind/authenticator_state_update.rs b/crates/iota-graphql-rpc/src/types/transaction_block_kind/authenticator_state_update.rs index 2333105622b..d543670d4f8 100644 --- a/crates/iota-graphql-rpc/src/types/transaction_block_kind/authenticator_state_update.rs +++ b/crates/iota-graphql-rpc/src/types/transaction_block_kind/authenticator_state_update.rs @@ -8,7 +8,7 @@ use async_graphql::{ }; use iota_types::{ authenticator_state::ActiveJwk as NativeActiveJwk, - transaction::AuthenticatorStateUpdate as NativeAuthenticatorStateUpdateTransaction, + transaction::AuthenticatorStateUpdateV1 as NativeAuthenticatorStateUpdateTransactionV1, }; use crate::{ @@ -22,7 +22,7 @@ use crate::{ #[derive(Clone, PartialEq, Eq)] pub(crate) struct AuthenticatorStateUpdateTransaction { - pub native: NativeAuthenticatorStateUpdateTransaction, + pub native: NativeAuthenticatorStateUpdateTransactionV1, /// The checkpoint sequence number this was viewed at. pub checkpoint_viewed_at: u64, } diff --git a/crates/iota-graphql-rpc/src/types/transaction_block_kind/end_of_epoch.rs b/crates/iota-graphql-rpc/src/types/transaction_block_kind/end_of_epoch.rs index 0ac44a456a8..45df35c47bd 100644 --- a/crates/iota-graphql-rpc/src/types/transaction_block_kind/end_of_epoch.rs +++ b/crates/iota-graphql-rpc/src/types/transaction_block_kind/end_of_epoch.rs @@ -235,7 +235,7 @@ impl AuthenticatorStateExpireTransaction { .extend() } - /// The initial version that the AuthenticatorStateUpdate was shared at. + /// The initial version that the AuthenticatorStateUpdateV1 was shared at. async fn authenticator_obj_initial_shared_version(&self) -> UInt53 { self.native .authenticator_obj_initial_shared_version diff --git a/crates/iota-graphql-rpc/src/types/transaction_block_kind/mod.rs b/crates/iota-graphql-rpc/src/types/transaction_block_kind/mod.rs index a5d8f4b1519..5d0c4f8685c 100644 --- a/crates/iota-graphql-rpc/src/types/transaction_block_kind/mod.rs +++ b/crates/iota-graphql-rpc/src/types/transaction_block_kind/mod.rs @@ -53,7 +53,7 @@ impl TransactionBlockKind { checkpoint_viewed_at, }) } - K::AuthenticatorStateUpdate(asu) => { + K::AuthenticatorStateUpdateV1(asu) => { T::AuthenticatorState(AuthenticatorStateUpdateTransaction { native: asu, checkpoint_viewed_at, diff --git a/crates/iota-graphql-rpc/src/types/validator.rs b/crates/iota-graphql-rpc/src/types/validator.rs index 44da1a62143..4bf76f499bf 100644 --- a/crates/iota-graphql-rpc/src/types/validator.rs +++ b/crates/iota-graphql-rpc/src/types/validator.rs @@ -216,7 +216,7 @@ impl Validator { Ok(None) } - /// The ID of this validator's `0x3::staking_pool::StakingPool`. + /// The ID of this validator's `0x3::staking_pool::StakingPoolV1`. async fn staking_pool_id(&self) -> IotaAddress { self.validator_summary.staking_pool_id.into() } diff --git a/crates/iota-graphql-rpc/tests/snapshots/snapshot_tests__schema_sdl_export.snap b/crates/iota-graphql-rpc/tests/snapshots/snapshot_tests__schema_sdl_export.snap index 3713703a57d..b8f1c96b155 100644 --- a/crates/iota-graphql-rpc/tests/snapshots/snapshot_tests__schema_sdl_export.snap +++ b/crates/iota-graphql-rpc/tests/snapshots/snapshot_tests__schema_sdl_export.snap @@ -195,7 +195,7 @@ type AuthenticatorStateExpireTransaction { """ minEpoch: Epoch """ - The initial version that the AuthenticatorStateUpdate was shared at. + The initial version that the AuthenticatorStateUpdateV1 was shared at. """ authenticatorObjInitialSharedVersion: UInt53! } @@ -4404,7 +4404,7 @@ type Validator { """ stakingPool: MoveObject @deprecated(reason: "The staking pool is a wrapped object. Access its fields directly on the `Validator` type.") """ - The ID of this validator's `0x3::staking_pool::StakingPool`. + The ID of this validator's `0x3::staking_pool::StakingPoolV1`. """ stakingPoolId: IotaAddress! """ diff --git a/crates/iota-indexer/migrations/mysql/2024-04-24-180207_epochs/up.sql b/crates/iota-indexer/migrations/mysql/2024-04-24-180207_epochs/up.sql index 2dcb4d7c53d..396b8ee2511 100644 --- a/crates/iota-indexer/migrations/mysql/2024-04-24-180207_epochs/up.sql +++ b/crates/iota-indexer/migrations/mysql/2024-04-24-180207_epochs/up.sql @@ -13,7 +13,7 @@ CREATE TABLE epochs epoch_total_transactions BIGINT, last_checkpoint_id BIGINT, epoch_end_timestamp BIGINT, - -- The following fields are from SystemEpochInfoEvent emitted + -- The following fields are from SystemEpochInfoEventV1 emitted -- **after** advancing to the next epoch storage_fund_reinvestment BIGINT, storage_charge BIGINT, diff --git a/crates/iota-indexer/migrations/pg/2023-08-19-044052_epochs/up.sql b/crates/iota-indexer/migrations/pg/2023-08-19-044052_epochs/up.sql index 5b540121cb8..1a3a946f5ae 100644 --- a/crates/iota-indexer/migrations/pg/2023-08-19-044052_epochs/up.sql +++ b/crates/iota-indexer/migrations/pg/2023-08-19-044052_epochs/up.sql @@ -13,7 +13,7 @@ CREATE TABLE epochs epoch_total_transactions BIGINT, last_checkpoint_id BIGINT, epoch_end_timestamp BIGINT, - -- The following fields are from SystemEpochInfoEvent emitted + -- The following fields are from SystemEpochInfoEventV1 emitted -- **after** advancing to the next epoch storage_fund_reinvestment BIGINT, storage_charge BIGINT, diff --git a/crates/iota-indexer/src/handlers/checkpoint_handler.rs b/crates/iota-indexer/src/handlers/checkpoint_handler.rs index d6a7255322e..9d227892f54 100644 --- a/crates/iota-indexer/src/handlers/checkpoint_handler.rs +++ b/crates/iota-indexer/src/handlers/checkpoint_handler.rs @@ -18,7 +18,7 @@ use iota_types::{ base_types::ObjectID, dynamic_field::{DynamicFieldInfo, DynamicFieldName, DynamicFieldType}, effects::TransactionEffectsAPI, - event::SystemEpochInfoEvent, + event::SystemEpochInfoEventV1, iota_system_state::{ IotaSystemStateTrait, get_iota_system_state, iota_system_state_summary::IotaSystemStateSummary, @@ -234,12 +234,12 @@ where .find(|ev| ev.is_system_epoch_info_event()) .unwrap_or_else(|| { panic!( - "Can't find SystemEpochInfoEvent in epoch end checkpoint {}", + "Can't find SystemEpochInfoEventV1 in epoch end checkpoint {}", checkpoint_summary.sequence_number() ) }); - let event = bcs::from_bytes::(&epoch_event.contents)?; + let event = bcs::from_bytes::(&epoch_event.contents)?; // Now we just entered epoch X, we want to calculate the diff between // TotalTransactionsByEndOfEpoch(X-1) and TotalTransactionsByEndOfEpoch(X-2). diff --git a/crates/iota-indexer/src/types.rs b/crates/iota-indexer/src/types.rs index d193e65da1e..1047811851a 100644 --- a/crates/iota-indexer/src/types.rs +++ b/crates/iota-indexer/src/types.rs @@ -11,7 +11,7 @@ use iota_types::{ digests::TransactionDigest, dynamic_field::DynamicFieldInfo, effects::TransactionEffects, - event::SystemEpochInfoEvent, + event::SystemEpochInfoEventV1, iota_serde::IotaStructTag, iota_system_state::iota_system_state_summary::IotaSystemStateSummary, messages_checkpoint::{ @@ -122,7 +122,7 @@ impl IndexedEpochInfo { pub fn from_new_system_state_summary( new_system_state_summary: IotaSystemStateSummary, first_checkpoint_id: u64, - event: Option<&SystemEpochInfoEvent>, + event: Option<&SystemEpochInfoEventV1>, ) -> IndexedEpochInfo { Self { epoch: new_system_state_summary.epoch, @@ -146,7 +146,7 @@ impl IndexedEpochInfo { pub fn from_end_of_epoch_data( system_state_summary: &IotaSystemStateSummary, last_checkpoint_summary: &CertifiedCheckpointSummary, - event: &SystemEpochInfoEvent, + event: &SystemEpochInfoEventV1, network_total_tx_num_at_last_epoch_end: u64, ) -> IndexedEpochInfo { Self { diff --git a/crates/iota-json-rpc-types/src/iota_extended.rs b/crates/iota-json-rpc-types/src/iota_extended.rs index bf7d3688c1c..12ef19c1e2e 100644 --- a/crates/iota-json-rpc-types/src/iota_extended.rs +++ b/crates/iota-json-rpc-types/src/iota_extended.rs @@ -96,7 +96,7 @@ pub struct EndOfEpochInfo { #[schemars(with = "BigInt")] #[serde_as(as = "BigInt")] pub epoch_end_timestamp: u64, - /// existing fields from `SystemEpochInfoEvent` (without epoch) + /// existing fields from `SystemEpochInfoEventV1` (without epoch) #[schemars(with = "BigInt")] #[serde_as(as = "BigInt")] pub protocol_version: u64, diff --git a/crates/iota-json-rpc-types/src/iota_transaction.rs b/crates/iota-json-rpc-types/src/iota_transaction.rs index db463d126d0..af0cdca061b 100644 --- a/crates/iota-json-rpc-types/src/iota_transaction.rs +++ b/crates/iota-json-rpc-types/src/iota_transaction.rs @@ -415,7 +415,7 @@ pub enum IotaTransactionBlockKind { /// used in future transactions ProgrammableTransaction(IotaProgrammableTransactionBlock), /// A transaction which updates global authenticator state - AuthenticatorStateUpdate(IotaAuthenticatorStateUpdate), + AuthenticatorStateUpdateV1(IotaAuthenticatorStateUpdateV1), /// A transaction which updates global randomness state RandomnessStateUpdate(IotaRandomnessStateUpdate), /// The transaction which occurs only at the end of the epoch @@ -446,7 +446,7 @@ impl Display for IotaTransactionBlockKind { write!(writer, "Transaction Kind: Programmable")?; write!(writer, "{}", crate::displays::Pretty(p))?; } - Self::AuthenticatorStateUpdate(_) => { + Self::AuthenticatorStateUpdateV1(_) => { writeln!(writer, "Transaction Kind: Authenticator State Update")?; } Self::RandomnessStateUpdate(_) => { @@ -490,8 +490,8 @@ impl IotaTransactionBlockKind { TransactionKind::ProgrammableTransaction(p) => Self::ProgrammableTransaction( IotaProgrammableTransactionBlock::try_from(p, module_cache)?, ), - TransactionKind::AuthenticatorStateUpdate(update) => { - Self::AuthenticatorStateUpdate(IotaAuthenticatorStateUpdate { + TransactionKind::AuthenticatorStateUpdateV1(update) => { + Self::AuthenticatorStateUpdateV1(IotaAuthenticatorStateUpdateV1 { epoch: update.epoch, round: update.round, new_active_jwks: update @@ -576,8 +576,8 @@ impl IotaTransactionBlockKind { ) .await?, ), - TransactionKind::AuthenticatorStateUpdate(update) => { - Self::AuthenticatorStateUpdate(IotaAuthenticatorStateUpdate { + TransactionKind::AuthenticatorStateUpdateV1(update) => { + Self::AuthenticatorStateUpdateV1(IotaAuthenticatorStateUpdateV1 { epoch: update.epoch, round: update.round, new_active_jwks: update @@ -639,7 +639,7 @@ impl IotaTransactionBlockKind { Self::Genesis(_) => "Genesis", Self::ConsensusCommitPrologueV1(_) => "ConsensusCommitPrologueV1", Self::ProgrammableTransaction(_) => "ProgrammableTransaction", - Self::AuthenticatorStateUpdate(_) => "AuthenticatorStateUpdate", + Self::AuthenticatorStateUpdateV1(_) => "AuthenticatorStateUpdateV1", Self::RandomnessStateUpdate(_) => "RandomnessStateUpdate", Self::EndOfEpochTransaction(_) => "EndOfEpochTransaction", } @@ -1585,7 +1585,7 @@ pub struct IotaConsensusCommitPrologueV1 { #[serde_as] #[derive(Debug, Clone, Serialize, Deserialize, JsonSchema, PartialEq, Eq)] -pub struct IotaAuthenticatorStateUpdate { +pub struct IotaAuthenticatorStateUpdateV1 { #[schemars(with = "BigInt")] #[serde_as(as = "BigInt")] pub epoch: u64, diff --git a/crates/iota-json-rpc/src/coin_api.rs b/crates/iota-json-rpc/src/coin_api.rs index fb491c5a3a4..7d190781c82 100644 --- a/crates/iota-json-rpc/src/coin_api.rs +++ b/crates/iota-json-rpc/src/coin_api.rs @@ -1273,7 +1273,7 @@ mod tests { iota_system_state::{ IotaSystemState, iota_system_state_inner_v1::{ - IotaSystemStateInnerV1, StorageFundV1, SystemParametersV1, ValidatorSetV1, + IotaSystemStateV1, StorageFundV1, SystemParametersV1, ValidatorSetV1, }, }, }; @@ -1400,8 +1400,8 @@ mod tests { expected.assert_eq(error_result.message()); } - fn default_system_state() -> IotaSystemStateInnerV1 { - IotaSystemStateInnerV1 { + fn default_system_state() -> IotaSystemStateV1 { + IotaSystemStateV1 { epoch: Default::default(), protocol_version: Default::default(), system_state_version: Default::default(), @@ -1434,6 +1434,7 @@ mod tests { }, parameters: SystemParametersV1 { epoch_duration_ms: Default::default(), + min_validator_count: Default::default(), max_validator_count: Default::default(), min_validator_joining_stake: Default::default(), validator_low_stake_threshold: Default::default(), diff --git a/crates/iota-json-rpc/src/transaction_execution_api.rs b/crates/iota-json-rpc/src/transaction_execution_api.rs index 6bde8958932..0d128dd1914 100644 --- a/crates/iota-json-rpc/src/transaction_execution_api.rs +++ b/crates/iota-json-rpc/src/transaction_execution_api.rs @@ -24,7 +24,7 @@ use iota_types::{ effects::TransactionEffectsAPI, iota_serde::BigInt, quorum_driver_types::{ - ExecuteTransactionRequestType, ExecuteTransactionRequestV3, ExecuteTransactionResponseV3, + ExecuteTransactionRequestType, ExecuteTransactionRequestV1, ExecuteTransactionResponseV1, }, signature::GenericSignature, storage::PostExecutionPackageResolver, @@ -79,7 +79,7 @@ impl TransactionExecutionApi { opts: Option, ) -> Result< ( - ExecuteTransactionRequestV3, + ExecuteTransactionRequestV1, IotaTransactionBlockResponseOptions, IotaAddress, Vec, @@ -116,7 +116,7 @@ impl TransactionExecutionApi { None }; - let request = ExecuteTransactionRequestV3 { + let request = ExecuteTransactionRequestV1 { transaction: txn.clone(), include_events: opts.show_events, include_input_objects: opts.show_balance_changes || opts.show_object_changes, @@ -175,7 +175,7 @@ impl TransactionExecutionApi { async fn handle_post_orchestration( &self, - response: ExecuteTransactionResponseV3, + response: ExecuteTransactionResponseV1, is_executed_locally: bool, opts: IotaTransactionBlockResponseOptions, digest: TransactionDigest, diff --git a/crates/iota-node/src/lib.rs b/crates/iota-node/src/lib.rs index 47bd2af4379..a76819def65 100644 --- a/crates/iota-node/src/lib.rs +++ b/crates/iota-node/src/lib.rs @@ -770,7 +770,6 @@ impl IotaNode { let accumulator = Arc::new(StateAccumulator::new( cache_traits.accumulator_store.clone(), - &epoch_store, StateAccumulatorMetrics::new(&prometheus_registry), )); @@ -1690,7 +1689,6 @@ impl IotaNode { .metrics(); let new_accumulator = Arc::new(StateAccumulator::new( self.state.get_accumulator_store().clone(), - &new_epoch_store, accumulator_metrics, )); let weak_accumulator = Arc::downgrade(&new_accumulator); @@ -1742,7 +1740,6 @@ impl IotaNode { .metrics(); let new_accumulator = Arc::new(StateAccumulator::new( self.state.get_accumulator_store().clone(), - &new_epoch_store, accumulator_metrics, )); let weak_accumulator = Arc::downgrade(&new_accumulator); diff --git a/crates/iota-open-rpc/spec/openrpc.json b/crates/iota-open-rpc/spec/openrpc.json index 6cd8db0c7de..f9fd7ae2d7e 100644 --- a/crates/iota-open-rpc/spec/openrpc.json +++ b/crates/iota-open-rpc/spec/openrpc.json @@ -6591,7 +6591,7 @@ "$ref": "#/components/schemas/BigInt_for_uint64" }, "protocolVersion": { - "description": "existing fields from `SystemEpochInfoEvent` (without epoch)", + "description": "existing fields from `SystemEpochInfoEventV1` (without epoch)", "allOf": [ { "$ref": "#/components/schemas/BigInt_for_uint64" @@ -11293,7 +11293,7 @@ "kind": { "type": "string", "enum": [ - "AuthenticatorStateUpdate" + "AuthenticatorStateUpdateV1" ] }, "new_active_jwks": { diff --git a/crates/iota-replay/src/types.rs b/crates/iota-replay/src/types.rs index d10d2519f4d..11ca9df050c 100644 --- a/crates/iota-replay/src/types.rs +++ b/crates/iota-replay/src/types.rs @@ -34,7 +34,7 @@ pub(crate) const MAX_CONCURRENT_REQUESTS: usize = 1_000; // Struct tag used in system epoch change events pub(crate) const EPOCH_CHANGE_STRUCT_TAG: &str = - "0x3::iota_system_state_inner::SystemEpochInfoEvent"; + "0x3::iota_system_state_inner::SystemEpochInfoEventV1"; // TODO: A lot of the information in OnChainTransactionInfo is redundant from // what's already in SenderSignedData. We should consider removing them. diff --git a/crates/iota-rest-api/src/transactions/execution.rs b/crates/iota-rest-api/src/transactions/execution.rs index 7ec25549736..00638f3fe90 100644 --- a/crates/iota-rest-api/src/transactions/execution.rs +++ b/crates/iota-rest-api/src/transactions/execution.rs @@ -73,7 +73,7 @@ async fn execute_transaction( Bcs(transaction): Bcs, ) -> Result> { let executor = state.ok_or_else(|| anyhow::anyhow!("No Transaction Executor"))?; - let request = iota_types::quorum_driver_types::ExecuteTransactionRequestV3 { + let request = iota_types::quorum_driver_types::ExecuteTransactionRequestV1 { transaction: transaction.into(), include_events: parameters.events, include_input_objects: parameters.input_objects || parameters.balance_changes, @@ -81,7 +81,7 @@ async fn execute_transaction( include_auxiliary_data: false, }; - let iota_types::quorum_driver_types::ExecuteTransactionResponseV3 { + let iota_types::quorum_driver_types::ExecuteTransactionResponseV1 { effects, events, input_objects, diff --git a/crates/iota-rosetta/src/types.rs b/crates/iota-rosetta/src/types.rs index 26bea52a93b..8f84205fa94 100644 --- a/crates/iota-rosetta/src/types.rs +++ b/crates/iota-rosetta/src/types.rs @@ -416,7 +416,7 @@ pub enum OperationType { Genesis, ConsensusCommitPrologue, ProgrammableTransaction, - AuthenticatorStateUpdate, + AuthenticatorStateUpdateV1, RandomnessStateUpdate, EndOfEpochTransaction, } @@ -431,8 +431,8 @@ impl From<&IotaTransactionBlockKind> for OperationType { IotaTransactionBlockKind::ProgrammableTransaction(_) => { OperationType::ProgrammableTransaction } - IotaTransactionBlockKind::AuthenticatorStateUpdate(_) => { - OperationType::AuthenticatorStateUpdate + IotaTransactionBlockKind::AuthenticatorStateUpdateV1(_) => { + OperationType::AuthenticatorStateUpdateV1 } IotaTransactionBlockKind::RandomnessStateUpdate(_) => { OperationType::RandomnessStateUpdate diff --git a/crates/iota-single-node-benchmark/src/single_node.rs b/crates/iota-single-node-benchmark/src/single_node.rs index fd066c470e7..fec55864d25 100644 --- a/crates/iota-single-node-benchmark/src/single_node.rs +++ b/crates/iota-single-node-benchmark/src/single_node.rs @@ -286,7 +286,6 @@ impl SingleValidator { validator.clone(), Arc::new(StateAccumulator::new_for_tests( validator.get_accumulator_store().clone(), - self.get_epoch_store(), )), ); (checkpoint_executor, ckpt_sender) diff --git a/crates/iota-storage/src/indexes.rs b/crates/iota-storage/src/indexes.rs index 449fed79efa..2345a956180 100644 --- a/crates/iota-storage/src/indexes.rs +++ b/crates/iota-storage/src/indexes.rs @@ -160,33 +160,12 @@ pub struct IndexStoreTables { #[default_options_override_fn = "transactions_to_addr_table_default_config"] transactions_to_addr: DBMap<(IotaAddress, TxSequenceNumber), TransactionDigest>, - /// Index from object id to transactions that used that object id as input. - #[deprecated] - transactions_by_input_object_id: DBMap<(ObjectID, TxSequenceNumber), TransactionDigest>, - - /// Index from object id to transactions that modified/created that object - /// id. - #[deprecated] - transactions_by_mutated_object_id: DBMap<(ObjectID, TxSequenceNumber), TransactionDigest>, - /// Index from package id, module and function identifier to transactions /// that used that moce function call as input. #[default_options_override_fn = "transactions_by_move_function_table_default_config"] transactions_by_move_function: DBMap<(ObjectID, String, String, TxSequenceNumber), TransactionDigest>, - /// This is a map between the transaction digest and its timestamp (UTC - /// timestamp in **milliseconds** since epoch 1/1/1970). A transaction - /// digest is subjectively time stamped on a node according to the local - /// machine time, so it varies across nodes. The timestamping happens - /// when the node sees a txn certificate for the first time. - /// - /// DEPRECATED. DO NOT USE - #[allow(dead_code)] - #[default_options_override_fn = "timestamps_table_default_config"] - #[deprecated] - timestamps: DBMap, - /// Ordering of all indexed transactions. #[default_options_override_fn = "transactions_order_table_default_config"] transaction_order: DBMap, @@ -214,20 +193,21 @@ pub struct IndexStoreTables { #[default_options_override_fn = "dynamic_field_index_table_default_config"] dynamic_field_index: DBMap, - /// This is an index of all the versions of loaded child objects - #[deprecated] - loaded_child_object_versions: DBMap>, - #[default_options_override_fn = "index_table_default_config"] event_order: DBMap, + #[default_options_override_fn = "index_table_default_config"] event_by_move_module: DBMap<(ModuleId, EventId), EventIndex>, + #[default_options_override_fn = "index_table_default_config"] event_by_move_event: DBMap<(StructTag, EventId), EventIndex>, + #[default_options_override_fn = "index_table_default_config"] event_by_event_module: DBMap<(ModuleId, EventId), EventIndex>, + #[default_options_override_fn = "index_table_default_config"] event_by_sender: DBMap<(IotaAddress, EventId), EventIndex>, + #[default_options_override_fn = "index_table_default_config"] event_by_time: DBMap<(u64, EventId), EventIndex>, } @@ -270,11 +250,6 @@ fn transactions_to_addr_table_default_config() -> DBOptions { fn transactions_by_move_function_table_default_config() -> DBOptions { default_db_options().disable_write_throttling() } -fn timestamps_table_default_config() -> DBOptions { - default_db_options() - .optimize_for_point_lookup(64) - .disable_write_throttling() -} fn owner_index_table_default_config() -> DBOptions { default_db_options().disable_write_throttling() } @@ -483,7 +458,6 @@ impl IndexStore { pub async fn index_tx( &self, sender: IotaAddress, - active_inputs: impl Iterator, mutated_objects: impl Iterator + Clone, move_functions: impl Iterator + Clone, events: &TransactionEvents, @@ -510,21 +484,6 @@ impl IndexStore { std::iter::once(((sender, sequence), *digest)), )?; - #[allow(deprecated)] - if !self.remove_deprecated_tables { - batch.insert_batch( - &self.tables.transactions_by_input_object_id, - active_inputs.map(|id| ((id, sequence), *digest)), - )?; - - batch.insert_batch( - &self.tables.transactions_by_mutated_object_id, - mutated_objects - .clone() - .map(|(obj_ref, _)| ((obj_ref.0, sequence), *digest)), - )?; - } - batch.insert_batch( &self.tables.transactions_by_move_function, move_functions.map(|(obj_id, module, function)| { @@ -698,12 +657,6 @@ impl IndexStore { }) => Ok(self.get_transactions_by_move_function( package, module, function, cursor, limit, reverse, )?), - Some(TransactionFilter::InputObject(object_id)) => { - Ok(self.get_transactions_by_input_object(object_id, cursor, limit, reverse)?) - } - Some(TransactionFilter::ChangedObject(object_id)) => { - Ok(self.get_transactions_by_mutated_object(object_id, cursor, limit, reverse)?) - } Some(TransactionFilter::FromAddress(address)) => { Ok(self.get_transactions_from_addr(address, cursor, limit, reverse)?) } @@ -781,46 +734,6 @@ impl IndexStore { }) } - pub fn get_transactions_by_input_object( - &self, - input_object: ObjectID, - cursor: Option, - limit: Option, - reverse: bool, - ) -> IotaResult> { - if self.remove_deprecated_tables { - return Ok(vec![]); - } - #[allow(deprecated)] - Self::get_transactions_from_index( - &self.tables.transactions_by_input_object_id, - input_object, - cursor, - limit, - reverse, - ) - } - - pub fn get_transactions_by_mutated_object( - &self, - mutated_object: ObjectID, - cursor: Option, - limit: Option, - reverse: bool, - ) -> IotaResult> { - if self.remove_deprecated_tables { - return Ok(vec![]); - } - #[allow(deprecated)] - Self::get_transactions_from_index( - &self.tables.transactions_by_mutated_object_id, - mutated_object, - cursor, - limit, - reverse, - ) - } - pub fn get_transactions_from_addr( &self, addr: IotaAddress, @@ -1655,7 +1568,6 @@ mod tests { address, vec![].into_iter(), vec![].into_iter(), - vec![].into_iter(), &TransactionEvents { data: vec![] }, object_index_changes, &TransactionDigest::random(), @@ -1699,7 +1611,6 @@ mod tests { address, vec![].into_iter(), vec![].into_iter(), - vec![].into_iter(), &TransactionEvents { data: vec![] }, object_index_changes, &TransactionDigest::random(), diff --git a/crates/iota-storage/tests/key_value_tests.rs b/crates/iota-storage/tests/key_value_tests.rs index ec2eaf956c3..f71ee6e9cbb 100644 --- a/crates/iota-storage/tests/key_value_tests.rs +++ b/crates/iota-storage/tests/key_value_tests.rs @@ -446,23 +446,6 @@ mod simtests { use super::*; - async fn svc( - State(state): State>>>>, - request: Request, - ) -> Response { - let path = request.uri().path().to_string(); - let key = path.trim_start_matches('/'); - let value = state.lock().unwrap().get(key).cloned(); - info!("Got request for key: {:?}, value: {:?}", key, value); - match value { - Some(v) => Response::new(Body::from(v)), - None => Response::builder() - .status(hyper::StatusCode::NOT_FOUND) - .body(Body::empty()) - .unwrap(), - } - } - async fn test_server(data: Arc>>>) { let handle = iota_simulator::runtime::Handle::current(); let builder = handle.create_node(); diff --git a/crates/iota-swarm-config/src/network_config_builder.rs b/crates/iota-swarm-config/src/network_config_builder.rs index 6add83639f6..cf9084b29cf 100644 --- a/crates/iota-swarm-config/src/network_config_builder.rs +++ b/crates/iota-swarm-config/src/network_config_builder.rs @@ -67,12 +67,12 @@ pub enum ProtocolVersionsConfig { PerValidator(SupportedProtocolVersionsCallback), } -pub type StateAccumulatorV2EnabledCallback = Arc bool + Send + Sync + 'static>; +pub type StateAccumulatorEnabledCallback = Arc bool + Send + Sync + 'static>; #[derive(Clone)] -pub enum StateAccumulatorV2EnabledConfig { +pub enum StateAccumulatorV1EnabledConfig { Global(bool), - PerValidator(StateAccumulatorV2EnabledCallback), + PerValidator(StateAccumulatorEnabledCallback), } pub struct ConfigBuilder { @@ -91,7 +91,7 @@ pub struct ConfigBuilder { firewall_config: Option, max_submit_position: Option, submit_delay_step_override_millis: Option, - state_accumulator_v2_enabled_config: Option, + state_accumulator_config: Option, empty_validator_genesis: bool, } @@ -113,7 +113,7 @@ impl ConfigBuilder { firewall_config: None, max_submit_position: None, submit_delay_step_override_millis: None, - state_accumulator_v2_enabled_config: None, + state_accumulator_config: Some(StateAccumulatorV1EnabledConfig::Global(true)), empty_validator_genesis: false, } } @@ -232,26 +232,16 @@ impl ConfigBuilder { self } - pub fn with_state_accumulator_v2_enabled(mut self, enabled: bool) -> Self { - self.state_accumulator_v2_enabled_config = - Some(StateAccumulatorV2EnabledConfig::Global(enabled)); - self - } - - pub fn with_state_accumulator_v2_enabled_callback( + pub fn with_state_accumulator_callback( mut self, - func: StateAccumulatorV2EnabledCallback, + func: StateAccumulatorEnabledCallback, ) -> Self { - self.state_accumulator_v2_enabled_config = - Some(StateAccumulatorV2EnabledConfig::PerValidator(func)); + self.state_accumulator_config = Some(StateAccumulatorV1EnabledConfig::PerValidator(func)); self } - pub fn with_state_accumulator_v2_enabled_config( - mut self, - c: StateAccumulatorV2EnabledConfig, - ) -> Self { - self.state_accumulator_v2_enabled_config = Some(c); + pub fn with_state_accumulator_config(mut self, c: StateAccumulatorV1EnabledConfig) -> Self { + self.state_accumulator_config = Some(c); self } @@ -300,7 +290,7 @@ impl ConfigBuilder { firewall_config: self.firewall_config, max_submit_position: self.max_submit_position, submit_delay_step_override_millis: self.submit_delay_step_override_millis, - state_accumulator_v2_enabled_config: self.state_accumulator_v2_enabled_config, + state_accumulator_config: self.state_accumulator_config, empty_validator_genesis: self.empty_validator_genesis, } } @@ -509,14 +499,6 @@ impl ConfigBuilder { }; builder = builder.with_supported_protocol_versions(supported_versions); } - if let Some(acc_v2_config) = &self.state_accumulator_v2_enabled_config { - let state_accumulator_v2_enabled: bool = match acc_v2_config { - StateAccumulatorV2EnabledConfig::Global(enabled) => *enabled, - StateAccumulatorV2EnabledConfig::PerValidator(func) => func(idx), - }; - builder = - builder.with_state_accumulator_v2_enabled(state_accumulator_v2_enabled); - } if let Some(num_unpruned_validators) = self.num_unpruned_validators { if idx < num_unpruned_validators { builder = builder.with_unpruned_checkpoints(); diff --git a/crates/iota-swarm-config/src/node_config_builder.rs b/crates/iota-swarm-config/src/node_config_builder.rs index 6b1fda9bf48..c95486df704 100644 --- a/crates/iota-swarm-config/src/node_config_builder.rs +++ b/crates/iota-swarm-config/src/node_config_builder.rs @@ -47,13 +47,11 @@ pub struct ValidatorConfigBuilder { firewall_config: Option, max_submit_position: Option, submit_delay_step_override_millis: Option, - state_accumulator_v2: bool, } impl ValidatorConfigBuilder { pub fn new() -> Self { Self { - state_accumulator_v2: true, ..Default::default() } } @@ -116,11 +114,6 @@ impl ValidatorConfigBuilder { self } - pub fn with_state_accumulator_v2_enabled(mut self, enabled: bool) -> Self { - self.state_accumulator_v2 = enabled; - self - } - pub fn build_without_genesis(self, validator: ValidatorGenesisConfig) -> NodeConfig { let key_path = get_key_path(&validator.authority_key_pair); let config_directory = self @@ -226,7 +219,6 @@ impl ValidatorConfigBuilder { policy_config: self.policy_config, firewall_config: self.firewall_config, execution_cache: ExecutionCacheConfig::default(), - state_accumulator_v2: self.state_accumulator_v2, enable_validator_tx_finalizer: true, } } @@ -515,7 +507,6 @@ impl FullnodeConfigBuilder { policy_config: self.policy_config, firewall_config: self.fw_config, execution_cache: ExecutionCacheConfig::default(), - state_accumulator_v2: true, // This is a validator specific feature. enable_validator_tx_finalizer: false, } diff --git a/crates/iota-swarm-config/tests/snapshots/snapshot_tests__populated_genesis_snapshot_matches-2.snap b/crates/iota-swarm-config/tests/snapshots/snapshot_tests__populated_genesis_snapshot_matches-2.snap index 1ac8f70c784..2e9909ef31f 100644 --- a/crates/iota-swarm-config/tests/snapshots/snapshot_tests__populated_genesis_snapshot_matches-2.snap +++ b/crates/iota-swarm-config/tests/snapshots/snapshot_tests__populated_genesis_snapshot_matches-2.snap @@ -8,7 +8,7 @@ system_state_version: 1 iota_treasury_cap: inner: id: - id: "0x9b65e25002180c54de255bdb2f31e22d63508231102ffb2fd27faa0f536de87f" + id: "0x7ba2382d99d4d34f39d55677d3cf8bace68ff9b414395e823f4b3b1f5b8779a9" total_supply: value: "751500000000000000" validators: @@ -244,13 +244,13 @@ validators: next_epoch_primary_address: ~ extra_fields: id: - id: "0xc6b6aca0ab617bca21813a8518f3805aeabfe4d7635dd57a9f0ebb888ae3139c" + id: "0x97c484626382f82340e8e1c6989a57d5ffd3471dadcb3d5405453f93f43cc9b0" size: 0 voting_power: 10000 - operation_cap_id: "0x548f60504903d7aaabdfd1a16410e3a3a3ae1953f8548c646219baa089b669f2" + operation_cap_id: "0x12c601377e08b9b1a4fc1eabbbd20e34f665b8a8d123c4ae0006afbdff96933b" gas_price: 1000 staking_pool: - id: "0x0521da3e38d78028af7ec630cbe948c1acaae39c6a35f67860f64420a4e0874e" + id: "0x4aaac511139597b1acd68475f3cf9a40a261d026db793d9bb9213228a6bc3a24" activation_epoch: 0 deactivation_epoch: ~ iota_balance: 1500000000000000 @@ -258,14 +258,14 @@ validators: value: 0 pool_token_balance: 1500000000000000 exchange_rates: - id: "0x772209f04fbf04034627dd991e8e99e61cf0c91afbb400f7812f784bfb67334a" + id: "0x358794a785d7ea4e4b953814e677ad1d3d580e480d99ee32fe7133f1aad50d8b" size: 1 pending_stake: 0 pending_total_iota_withdraw: 0 pending_pool_token_withdraw: 0 extra_fields: id: - id: "0x76c3c9a30c02e26059dac95e558b0ca7bbe705c92da04625f832aaba7328e372" + id: "0x215369ce1b8cd5ae13d92e7466d6448898f63362e92c22db9ed671bee1fd6e37" size: 0 commission_rate: 200 next_epoch_stake: 1500000000000000 @@ -273,27 +273,27 @@ validators: next_epoch_commission_rate: 200 extra_fields: id: - id: "0x5a1a6ab293e72e1181c1bd07cf2b54499396de703a97b80fdb7498c975437a28" + id: "0xb124b29bc0bb01f4ba0833d2c52c860614def31cbe0cb6bb2500d20a2ef518aa" size: 0 pending_active_validators: contents: - id: "0x39d738794b40d46afa04360d00f3c8104d7eb0b03efb286b003ad9be3b7d2771" + id: "0x894ec4c364d05c6d7b8c65d791261efe8c07a1c38ba843a3a37df40536cc2c6f" size: 0 pending_removals: [] staking_pool_mappings: - id: "0xd5fe9bfde8d78dc9eb379f3728b4a9666a21395d4584e33a5a44bafbaa45e742" + id: "0x81109e3abf78a50ba7f74a043049c5a3df88c848e929913da5c287e5f0e1de86" size: 1 inactive_validators: - id: "0x9ed702f0e91e000c7c30540c8d57aee84b0456044c252e3c5219974a93e77ea3" + id: "0xed8eaac07f4ccec9088a814ec9169a8ec87586f15797ff6d4b80d089a95c724c" size: 0 validator_candidates: - id: "0xa0cb26c1edea2745ac6f2eca051fed26f90eddb4d9c540439a6fd50f01ffd580" + id: "0x9c0ce6b24517363f21e543c12a51ed36ff4a252d9446ec6aaffc9074faed79ff" size: 0 at_risk_validators: contents: [] extra_fields: id: - id: "0x094fe2d3f1496b5b653ab2ae99f8c5fc6c8733b00bec5a95e831c54b0d156c9a" + id: "0xf8f51ed1b0cc6fbe3a803637728dd8e21f07f90eb3a5acde5ae2f9df3a0f222e" size: 0 storage_fund: total_object_storage_rebates: @@ -302,6 +302,7 @@ storage_fund: value: 0 parameters: epoch_duration_ms: 86400000 + min_validator_count: 4 max_validator_count: 150 min_validator_joining_stake: 2000000000000000 validator_low_stake_threshold: 1500000000000000 @@ -309,7 +310,7 @@ parameters: validator_low_stake_grace_period: 7 extra_fields: id: - id: "0xb91c535b339544d3286d75d212d039bd29355a22f168a7b0354fca7f7657a400" + id: "0x552e25d51ce8d5164c92471ac952a46a93645fa8337f00abe6cec8a87e89423c" size: 0 reference_gas_price: 1000 validator_report_records: @@ -324,5 +325,5 @@ safe_mode_non_refundable_storage_fee: 0 epoch_start_timestamp_ms: 10 extra_fields: id: - id: "0xce536abd7e6b6f1a3b551b756f1504d991166fdfd57bb04ebbe400c1ede47848" + id: "0xfc995fb81559a3d5e8e8e186bb6fc16a906e2b789ecb032e977003f3498f49b7" size: 0 diff --git a/crates/iota-swarm/src/memory/swarm.rs b/crates/iota-swarm/src/memory/swarm.rs index 65145e1e306..0824335e0e2 100644 --- a/crates/iota-swarm/src/memory/swarm.rs +++ b/crates/iota-swarm/src/memory/swarm.rs @@ -24,7 +24,7 @@ use iota_swarm_config::{ genesis_config::{AccountConfig, GenesisConfig, ValidatorGenesisConfig}, network_config::NetworkConfig, network_config_builder::{ - CommitteeConfig, ConfigBuilder, ProtocolVersionsConfig, StateAccumulatorV2EnabledConfig, + CommitteeConfig, ConfigBuilder, ProtocolVersionsConfig, StateAccumulatorV1EnabledConfig, SupportedProtocolVersionsCallback, }, node_config_builder::FullnodeConfigBuilder, @@ -65,7 +65,7 @@ pub struct SwarmBuilder { fullnode_fw_config: Option, max_submit_position: Option, submit_delay_step_override_millis: Option, - state_accumulator_v2_enabled_config: StateAccumulatorV2EnabledConfig, + state_accumulator_config: StateAccumulatorV1EnabledConfig, } impl SwarmBuilder { @@ -93,7 +93,7 @@ impl SwarmBuilder { fullnode_fw_config: None, max_submit_position: None, submit_delay_step_override_millis: None, - state_accumulator_v2_enabled_config: StateAccumulatorV2EnabledConfig::Global(true), + state_accumulator_config: StateAccumulatorV1EnabledConfig::Global(true), } } } @@ -123,7 +123,7 @@ impl SwarmBuilder { fullnode_fw_config: self.fullnode_fw_config, max_submit_position: self.max_submit_position, submit_delay_step_override_millis: self.submit_delay_step_override_millis, - state_accumulator_v2_enabled_config: self.state_accumulator_v2_enabled_config, + state_accumulator_config: self.state_accumulator_config, } } @@ -234,11 +234,8 @@ impl SwarmBuilder { self } - pub fn with_state_accumulator_v2_enabled_config( - mut self, - c: StateAccumulatorV2EnabledConfig, - ) -> Self { - self.state_accumulator_v2_enabled_config = c; + pub fn with_state_accumulator_config(mut self, c: StateAccumulatorV1EnabledConfig) -> Self { + self.state_accumulator_config = c; self } @@ -362,9 +359,7 @@ impl SwarmBuilder { .with_supported_protocol_versions_config( self.supported_protocol_versions_config.clone(), ) - .with_state_accumulator_v2_enabled_config( - self.state_accumulator_v2_enabled_config.clone(), - ) + .with_state_accumulator_config(self.state_accumulator_config.clone()) .build(); // Populate validator genesis by pointing to the blob let genesis_path = dir.join(IOTA_GENESIS_FILENAME); diff --git a/crates/iota-tool/src/db_tool/index_search.rs b/crates/iota-tool/src/db_tool/index_search.rs index f1977538141..694b610467d 100644 --- a/crates/iota-tool/src/db_tool/index_search.rs +++ b/crates/iota-tool/src/db_tool/index_search.rs @@ -67,22 +67,6 @@ pub fn search_index( termination ) } - "transactions_by_input_object_id" => { - get_db_entries!( - db_read_only_handle.transactions_by_input_object_id, - from_id_seq, - start, - termination - ) - } - "transactions_by_mutated_object_id" => { - get_db_entries!( - db_read_only_handle.transactions_by_mutated_object_id, - from_id_seq, - start, - termination - ) - } "transactions_by_move_function" => { get_db_entries!( db_read_only_handle.transactions_by_move_function, @@ -131,14 +115,6 @@ pub fn search_index( termination ) } - "loaded_child_object_versions" => { - get_db_entries!( - db_read_only_handle.loaded_child_object_versions, - TransactionDigest::from_str, - start, - termination - ) - } "event_by_event_module" => { get_db_entries!( db_read_only_handle.event_by_event_module, @@ -265,19 +241,6 @@ fn from_addr_seq(s: &str) -> Result<(IotaAddress, TxSequenceNumber), anyhow::Err Ok((address, sequence_number)) } -fn from_id_seq(s: &str) -> Result<(ObjectID, TxSequenceNumber), anyhow::Error> { - // Remove whitespaces - let s = s.trim(); - let tokens = s.split(',').collect::>(); - if tokens.len() != 2 { - return Err(anyhow!("Invalid object id, sequence number pair")); - } - let oid = ObjectID::from_str(tokens[0].trim())?; - let sequence_number = TxSequenceNumber::from_str(tokens[1].trim())?; - - Ok((oid, sequence_number)) -} - fn from_id_module_function_txseq( s: &str, ) -> Result<(ObjectID, String, String, TxSequenceNumber), anyhow::Error> { diff --git a/crates/iota-types/src/event.rs b/crates/iota-types/src/event.rs index ba43c026b35..f879bc64d2e 100755 --- a/crates/iota-types/src/event.rs +++ b/crates/iota-types/src/event.rs @@ -141,7 +141,7 @@ impl Event { pub fn is_system_epoch_info_event(&self) -> bool { self.type_.address == IOTA_SYSTEM_ADDRESS && self.type_.module.as_ident_str() == ident_str!("iota_system_state_inner") - && self.type_.name.as_ident_str() == ident_str!("SystemEpochInfoEvent") + && self.type_.name.as_ident_str() == ident_str!("SystemEpochInfoEventV1") } } @@ -164,7 +164,7 @@ impl Event { // Event emitted in move code `fun advance_epoch` #[derive(Deserialize)] -pub struct SystemEpochInfoEvent { +pub struct SystemEpochInfoEventV1 { pub epoch: u64, pub protocol_version: u64, pub reference_gas_price: u64, diff --git a/crates/iota-types/src/iota_system_state/iota_system_state_inner_v1.rs b/crates/iota-types/src/iota_system_state/iota_system_state_inner_v1.rs index 3246042c5d0..d373cdbbd01 100644 --- a/crates/iota-types/src/iota_system_state/iota_system_state_inner_v1.rs +++ b/crates/iota-types/src/iota_system_state/iota_system_state_inner_v1.rs @@ -44,6 +44,9 @@ pub struct SystemParametersV1 { /// The duration of an epoch, in milliseconds. pub epoch_duration_ms: u64, + /// Minimum number of active validators at any moment. + pub min_validator_count: u64, + /// Maximum number of active validators at any moment. /// We do not allow the number of validators in any epoch to go above this. pub max_validator_count: u64, @@ -272,7 +275,7 @@ impl ValidatorMetadataV1 { } } -/// Rust version of the Move iota::validator::Validator type +/// Rust version of the Move iota::validator::ValidatorV1 type #[derive(Debug, Serialize, Deserialize, Clone, Eq, PartialEq)] pub struct ValidatorV1 { metadata: ValidatorMetadataV1, @@ -394,7 +397,7 @@ impl ValidatorV1 { } } -/// Rust version of the Move iota_system::staking_pool::StakingPool type +/// Rust version of the Move iota_system::staking_pool::StakingPoolV1 type #[derive(Debug, Serialize, Deserialize, Clone, Eq, PartialEq)] pub struct StakingPoolV1 { pub id: ObjectID, @@ -410,7 +413,7 @@ pub struct StakingPoolV1 { pub extra_fields: Bag, } -/// Rust version of the Move iota_system::validator_set::ValidatorSet type +/// Rust version of the Move iota_system::validator_set::ValidatorSetV1 type #[derive(Debug, Serialize, Deserialize, Clone, Eq, PartialEq)] pub struct ValidatorSetV1 { pub total_stake: u64, @@ -424,16 +427,16 @@ pub struct ValidatorSetV1 { pub extra_fields: Bag, } -/// Rust version of the Move iota_system::storage_fund::StorageFund type +/// Rust version of the Move iota_system::storage_fund::StorageFundV1 type #[derive(Debug, Serialize, Deserialize, Clone, Eq, PartialEq)] pub struct StorageFundV1 { pub total_object_storage_rebates: Balance, pub non_refundable_balance: Balance, } -/// Rust version of the Move iota_system::iota_system::IotaSystemStateInner type +/// Rust version of the Move iota_system::iota_system::IotaSystemStateV1 type #[derive(Debug, Serialize, Deserialize, Clone, Eq, PartialEq)] -pub struct IotaSystemStateInnerV1 { +pub struct IotaSystemStateV1 { pub epoch: u64, pub protocol_version: u64, pub system_state_version: u64, @@ -453,7 +456,7 @@ pub struct IotaSystemStateInnerV1 { // TODO: Use getters instead of all pub. } -impl IotaSystemStateTrait for IotaSystemStateInnerV1 { +impl IotaSystemStateTrait for IotaSystemStateV1 { fn epoch(&self) -> u64 { self.epoch } @@ -522,7 +525,7 @@ impl IotaSystemStateTrait for IotaSystemStateInnerV1 { let table_id = self.validators.pending_active_validators.contents.id; let table_size = self.validators.pending_active_validators.contents.size; let validators: Vec = - get_validators_from_table_vec(object_store, table_id, table_size)?; + get_validators_from_table_vec(&object_store, table_id, table_size)?; Ok(validators .into_iter() .map(|v| v.into_iota_validator_summary()) @@ -606,6 +609,7 @@ impl IotaSystemStateTrait for IotaSystemStateInnerV1 { parameters: SystemParametersV1 { epoch_duration_ms, + min_validator_count: _, /* TODO: Add it to RPC layer in the future https://github.com/iotaledger/iota/issues/3232. */ max_validator_count, min_validator_joining_stake, validator_low_stake_threshold, @@ -678,7 +682,7 @@ impl IotaSystemStateTrait for IotaSystemStateInnerV1 { /// Rust version of the Move /// iota_system::validator_cap::UnverifiedValidatorOperationCap type #[derive(Debug, Serialize, Deserialize, Clone, Eq, PartialEq)] -pub struct UnverifiedValidatorOperationCapV1 { +pub struct UnverifiedValidatorOperationCap { pub id: ObjectID, pub authorizer_validator_address: IotaAddress, } diff --git a/crates/iota-types/src/iota_system_state/iota_system_state_inner_v2.rs b/crates/iota-types/src/iota_system_state/iota_system_state_inner_v2.rs deleted file mode 100644 index 494593e78c1..00000000000 --- a/crates/iota-types/src/iota_system_state/iota_system_state_inner_v2.rs +++ /dev/null @@ -1,305 +0,0 @@ -// Copyright (c) Mysten Labs, Inc. -// Modifications Copyright (c) 2024 IOTA Stiftung -// SPDX-License-Identifier: Apache-2.0 - -use serde::{Deserialize, Serialize}; - -use super::{ - AdvanceEpochParams, IotaSystemStateTrait, - epoch_start_iota_system_state::EpochStartValidatorInfoV1, - iota_system_state_inner_v1::ValidatorV1, - iota_system_state_summary::{IotaSystemStateSummary, IotaValidatorSummary}, -}; -use crate::{ - balance::Balance, - base_types::IotaAddress, - collection_types::{Bag, Table, TableVec, VecMap, VecSet}, - committee::{CommitteeWithNetworkMetadata, NetworkMetadata}, - error::IotaError, - gas_coin::IotaTreasuryCap, - iota_system_state::{ - epoch_start_iota_system_state::EpochStartSystemState, - get_validators_from_table_vec, - iota_system_state_inner_v1::{StorageFundV1, ValidatorSetV1}, - }, - storage::ObjectStore, -}; - -/// Rust version of the Move iota::iota_system::SystemParametersV2 type -#[derive(Debug, Serialize, Deserialize, Clone, Eq, PartialEq)] -pub struct SystemParametersV2 { - /// The duration of an epoch, in milliseconds. - pub epoch_duration_ms: u64, - - /// Minimum number of active validators at any moment. - pub min_validator_count: u64, - - /// Maximum number of active validators at any moment. - /// We do not allow the number of validators in any epoch to go above this. - pub max_validator_count: u64, - - /// Lower-bound on the amount of stake required to become a validator. - pub min_validator_joining_stake: u64, - - /// Validators with stake amount below `validator_low_stake_threshold` are - /// considered to have low stake and will be escorted out of the - /// validator set after being below this threshold for more than - /// `validator_low_stake_grace_period` number of epochs. - pub validator_low_stake_threshold: u64, - - /// Validators with stake below `validator_very_low_stake_threshold` will be - /// removed immediately at epoch change, no grace period. - pub validator_very_low_stake_threshold: u64, - - /// A validator can have stake below `validator_low_stake_threshold` - /// for this many epochs before being kicked out. - pub validator_low_stake_grace_period: u64, - - pub extra_fields: Bag, -} - -/// Rust version of the Move iota_system::iota_system::IotaSystemStateInnerV2 -/// type -#[derive(Debug, Serialize, Deserialize, Clone, Eq, PartialEq)] -pub struct IotaSystemStateInnerV2 { - pub epoch: u64, - pub protocol_version: u64, - pub system_state_version: u64, - pub iota_treasury_cap: IotaTreasuryCap, - pub validators: ValidatorSetV1, - pub storage_fund: StorageFundV1, - pub parameters: SystemParametersV2, - pub reference_gas_price: u64, - pub validator_report_records: VecMap>, - pub safe_mode: bool, - pub safe_mode_storage_charges: Balance, - pub safe_mode_computation_rewards: Balance, - pub safe_mode_storage_rebates: u64, - pub safe_mode_non_refundable_storage_fee: u64, - pub epoch_start_timestamp_ms: u64, - pub extra_fields: Bag, - // TODO: Use getters instead of all pub. -} - -impl IotaSystemStateTrait for IotaSystemStateInnerV2 { - fn epoch(&self) -> u64 { - self.epoch - } - - fn reference_gas_price(&self) -> u64 { - self.reference_gas_price - } - - fn protocol_version(&self) -> u64 { - self.protocol_version - } - - fn system_state_version(&self) -> u64 { - self.system_state_version - } - - fn epoch_start_timestamp_ms(&self) -> u64 { - self.epoch_start_timestamp_ms - } - - fn epoch_duration_ms(&self) -> u64 { - self.parameters.epoch_duration_ms - } - - fn safe_mode(&self) -> bool { - self.safe_mode - } - - fn advance_epoch_safe_mode(&mut self, params: &AdvanceEpochParams) { - self.epoch = params.epoch; - self.safe_mode = true; - self.safe_mode_storage_charges - .deposit_for_safe_mode(params.storage_charge); - self.safe_mode_storage_rebates += params.storage_rebate; - self.safe_mode_computation_rewards - .deposit_for_safe_mode(params.computation_charge); - self.safe_mode_non_refundable_storage_fee += params.non_refundable_storage_fee; - self.epoch_start_timestamp_ms = params.epoch_start_timestamp_ms; - self.protocol_version = params.next_protocol_version.as_u64(); - } - - fn get_current_epoch_committee(&self) -> CommitteeWithNetworkMetadata { - let validators = self - .validators - .active_validators - .iter() - .map(|validator| { - let verified_metadata = validator.verified_metadata(); - let name = verified_metadata.iota_pubkey_bytes(); - ( - name, - (validator.voting_power, NetworkMetadata { - network_address: verified_metadata.net_address.clone(), - primary_address: verified_metadata.primary_address.clone(), - }), - ) - }) - .collect(); - CommitteeWithNetworkMetadata::new(self.epoch, validators) - } - - fn get_pending_active_validators( - &self, - object_store: &S, - ) -> Result, IotaError> { - let table_id = self.validators.pending_active_validators.contents.id; - let table_size = self.validators.pending_active_validators.contents.size; - let validators: Vec = - get_validators_from_table_vec(&object_store, table_id, table_size)?; - Ok(validators - .into_iter() - .map(|v| v.into_iota_validator_summary()) - .collect()) - } - - fn into_epoch_start_state(self) -> EpochStartSystemState { - EpochStartSystemState::new_v1( - self.epoch, - self.protocol_version, - self.reference_gas_price, - self.safe_mode, - self.epoch_start_timestamp_ms, - self.parameters.epoch_duration_ms, - self.validators - .active_validators - .iter() - .map(|validator| { - let metadata = validator.verified_metadata(); - EpochStartValidatorInfoV1 { - iota_address: metadata.iota_address, - authority_pubkey: metadata.authority_pubkey.clone(), - network_pubkey: metadata.network_pubkey.clone(), - protocol_pubkey: metadata.protocol_pubkey.clone(), - iota_net_address: metadata.net_address.clone(), - p2p_address: metadata.p2p_address.clone(), - primary_address: metadata.primary_address.clone(), - voting_power: validator.voting_power, - hostname: metadata.name.clone(), - } - }) - .collect(), - ) - } - - fn into_iota_system_state_summary(self) -> IotaSystemStateSummary { - // If you are making any changes to IotaSystemStateV1 or any of its dependent - // types before mainnet, please also update IotaSystemStateSummary and - // its corresponding TS type. Post-mainnet, we will need to introduce a - // new version. - let Self { - epoch, - protocol_version, - system_state_version, - iota_treasury_cap, - validators: - ValidatorSetV1 { - total_stake, - active_validators, - pending_active_validators: - TableVec { - contents: - Table { - id: pending_active_validators_id, - size: pending_active_validators_size, - }, - }, - pending_removals, - staking_pool_mappings: - Table { - id: staking_pool_mappings_id, - size: staking_pool_mappings_size, - }, - inactive_validators: - Table { - id: inactive_pools_id, - size: inactive_pools_size, - }, - validator_candidates: - Table { - id: validator_candidates_id, - size: validator_candidates_size, - }, - at_risk_validators: - VecMap { - contents: at_risk_validators, - }, - extra_fields: _, - }, - storage_fund, - parameters: - SystemParametersV2 { - epoch_duration_ms, - min_validator_count: _, // TODO: Add it to RPC layer in the future. - max_validator_count, - min_validator_joining_stake, - validator_low_stake_threshold, - validator_very_low_stake_threshold, - validator_low_stake_grace_period, - extra_fields: _, - }, - reference_gas_price, - validator_report_records: - VecMap { - contents: validator_report_records, - }, - safe_mode, - safe_mode_storage_charges, - safe_mode_computation_rewards, - safe_mode_storage_rebates, - safe_mode_non_refundable_storage_fee, - epoch_start_timestamp_ms, - extra_fields: _, - } = self; - IotaSystemStateSummary { - epoch, - protocol_version, - system_state_version, - iota_total_supply: iota_treasury_cap.total_supply().value, - iota_treasury_cap_id: iota_treasury_cap.id().to_owned(), - storage_fund_total_object_storage_rebates: storage_fund - .total_object_storage_rebates - .value(), - storage_fund_non_refundable_balance: storage_fund.non_refundable_balance.value(), - reference_gas_price, - safe_mode, - safe_mode_storage_charges: safe_mode_storage_charges.value(), - safe_mode_computation_rewards: safe_mode_computation_rewards.value(), - safe_mode_storage_rebates, - safe_mode_non_refundable_storage_fee, - epoch_start_timestamp_ms, - epoch_duration_ms, - total_stake, - active_validators: active_validators - .into_iter() - .map(|v| v.into_iota_validator_summary()) - .collect(), - pending_active_validators_id, - pending_active_validators_size, - pending_removals, - staking_pool_mappings_id, - staking_pool_mappings_size, - inactive_pools_id, - inactive_pools_size, - validator_candidates_id, - validator_candidates_size, - at_risk_validators: at_risk_validators - .into_iter() - .map(|e| (e.key, e.value)) - .collect(), - validator_report_records: validator_report_records - .into_iter() - .map(|e| (e.key, e.value.contents)) - .collect(), - max_validator_count, - min_validator_joining_stake, - validator_low_stake_threshold, - validator_very_low_stake_threshold, - validator_low_stake_grace_period, - } - } -} diff --git a/crates/iota-types/src/iota_system_state/mod.rs b/crates/iota-types/src/iota_system_state/mod.rs index 236d056e5fd..bdadfcada9a 100644 --- a/crates/iota-types/src/iota_system_state/mod.rs +++ b/crates/iota-types/src/iota_system_state/mod.rs @@ -11,7 +11,7 @@ use move_core_types::{ident_str, identifier::IdentStr, language_storage::StructT use serde::{Deserialize, Serialize, de::DeserializeOwned}; use self::{ - iota_system_state_inner_v1::{IotaSystemStateInnerV1, ValidatorV1}, + iota_system_state_inner_v1::{IotaSystemStateV1, ValidatorV1}, iota_system_state_summary::{IotaSystemStateSummary, IotaValidatorSummary}, }; use crate::{ @@ -21,10 +21,7 @@ use crate::{ dynamic_field::{Field, get_dynamic_field_from_store, get_dynamic_field_object_from_store}, error::IotaError, id::UID, - iota_system_state::{ - epoch_start_iota_system_state::EpochStartSystemState, - iota_system_state_inner_v2::IotaSystemStateInnerV2, - }, + iota_system_state::epoch_start_iota_system_state::EpochStartSystemState, object::{MoveObject, Object}, storage::ObjectStore, versioned::Versioned, @@ -32,15 +29,14 @@ use crate::{ pub mod epoch_start_iota_system_state; pub mod iota_system_state_inner_v1; -pub mod iota_system_state_inner_v2; pub mod iota_system_state_summary; #[cfg(msim)] mod simtest_iota_system_state_inner; #[cfg(msim)] use self::simtest_iota_system_state_inner::{ - SimTestIotaSystemStateInnerDeepV2, SimTestIotaSystemStateInnerShallowV2, - SimTestIotaSystemStateInnerV1, SimTestValidatorDeepV2, SimTestValidatorV1, + SimTestIotaSystemStateDeepV1, SimTestIotaSystemStateShallowV1, SimTestIotaSystemStateV1, + SimTestValidatorDeepV2, SimTestValidatorV1, }; const IOTA_SYSTEM_STATE_WRAPPER_STRUCT_NAME: &IdentStr = ident_str!("IotaSystemState"); @@ -52,9 +48,9 @@ pub const ADVANCE_EPOCH_SAFE_MODE_FUNCTION_NAME: &IdentStr = ident_str!("advance #[cfg(msim)] pub const IOTA_SYSTEM_STATE_SIM_TEST_V1: u64 = 18446744073709551605; // u64::MAX - 10 #[cfg(msim)] -pub const IOTA_SYSTEM_STATE_SIM_TEST_SHALLOW_V2: u64 = 18446744073709551606; // u64::MAX - 9 +pub const IOTA_SYSTEM_STATE_SIM_TEST_SHALLOW_V1: u64 = 18446744073709551606; // u64::MAX - 9 #[cfg(msim)] -pub const IOTA_SYSTEM_STATE_SIM_TEST_DEEP_V2: u64 = 18446744073709551607; // u64::MAX - 8 +pub const IOTA_SYSTEM_STATE_SIM_TEST_DEEP_V1: u64 = 18446744073709551607; // u64::MAX - 8 /// Rust version of the Move iota::iota_system::IotaSystemState type /// This repreents the object with 0x5 ID. @@ -100,14 +96,7 @@ impl IotaSystemStateWrapper { .expect("Dynamic field object must be a Move object"); match self.version { 1 => { - Self::advance_epoch_safe_mode_impl::( - move_object, - params, - protocol_config, - ); - } - 2 => { - Self::advance_epoch_safe_mode_impl::( + Self::advance_epoch_safe_mode_impl::( move_object, params, protocol_config, @@ -115,23 +104,23 @@ impl IotaSystemStateWrapper { } #[cfg(msim)] IOTA_SYSTEM_STATE_SIM_TEST_V1 => { - Self::advance_epoch_safe_mode_impl::( + Self::advance_epoch_safe_mode_impl::( move_object, params, protocol_config, ); } #[cfg(msim)] - IOTA_SYSTEM_STATE_SIM_TEST_SHALLOW_V2 => { - Self::advance_epoch_safe_mode_impl::( + IOTA_SYSTEM_STATE_SIM_TEST_SHALLOW_V1 => { + Self::advance_epoch_safe_mode_impl::( move_object, params, protocol_config, ); } #[cfg(msim)] - IOTA_SYSTEM_STATE_SIM_TEST_DEEP_V2 => { - Self::advance_epoch_safe_mode_impl::( + IOTA_SYSTEM_STATE_SIM_TEST_DEEP_V1 => { + Self::advance_epoch_safe_mode_impl::( move_object, params, protocol_config, @@ -200,18 +189,17 @@ pub trait IotaSystemStateTrait { #[derive(Debug, Serialize, Deserialize, Clone, Eq, PartialEq)] #[enum_dispatch(IotaSystemStateTrait)] pub enum IotaSystemState { - V1(IotaSystemStateInnerV1), - V2(IotaSystemStateInnerV2), + V1(IotaSystemStateV1), #[cfg(msim)] - SimTestV1(SimTestIotaSystemStateInnerV1), + SimTestV1(SimTestIotaSystemStateV1), #[cfg(msim)] - SimTestShallowV2(SimTestIotaSystemStateInnerShallowV2), + SimTestShallowV2(SimTestIotaSystemStateShallowV1), #[cfg(msim)] - SimTestDeepV2(SimTestIotaSystemStateInnerDeepV2), + SimTestDeepV2(SimTestIotaSystemStateDeepV1), } /// This is the fixed type used by genesis. -pub type IotaSystemStateInnerGenesis = IotaSystemStateInnerV1; +pub type IotaSystemStateInnerGenesis = IotaSystemStateV1; pub type IotaValidatorGenesis = ValidatorV1; impl IotaSystemState { @@ -223,7 +211,11 @@ impl IotaSystemState { pub fn into_genesis_version_for_tooling(self) -> IotaSystemStateInnerGenesis { match self { IotaSystemState::V1(inner) => inner, - _ => unreachable!(), + #[cfg(msim)] + _ => { + // Types other than V1 used in simtests should be unreachable + unreachable!() + } } } @@ -256,7 +248,7 @@ pub fn get_iota_system_state(object_store: &dyn ObjectStore) -> Result { - let result: IotaSystemStateInnerV1 = + let result: IotaSystemStateV1 = get_dynamic_field_from_store(object_store, id, &wrapper.version).map_err( |err| { IotaError::DynamicFieldRead(format!( @@ -267,21 +259,9 @@ pub fn get_iota_system_state(object_store: &dyn ObjectStore) -> Result { - let result: IotaSystemStateInnerV2 = - get_dynamic_field_from_store(object_store, id, &wrapper.version).map_err( - |err| { - IotaError::DynamicFieldRead(format!( - "Failed to load iota system state inner object with ID {:?} and version {:?}: {:?}", - id, wrapper.version, err - )) - }, - )?; - Ok(IotaSystemState::V2(result)) - } #[cfg(msim)] IOTA_SYSTEM_STATE_SIM_TEST_V1 => { - let result: SimTestIotaSystemStateInnerV1 = + let result: SimTestIotaSystemStateV1 = get_dynamic_field_from_store(object_store, id, &wrapper.version).map_err( |err| { IotaError::DynamicFieldRead(format!( @@ -293,8 +273,8 @@ pub fn get_iota_system_state(object_store: &dyn ObjectStore) -> Result { - let result: SimTestIotaSystemStateInnerShallowV2 = + IOTA_SYSTEM_STATE_SIM_TEST_SHALLOW_V1 => { + let result: SimTestIotaSystemStateShallowV1 = get_dynamic_field_from_store(object_store, id, &wrapper.version).map_err( |err| { IotaError::DynamicFieldRead(format!( @@ -306,8 +286,8 @@ pub fn get_iota_system_state(object_store: &dyn ObjectStore) -> Result { - let result: SimTestIotaSystemStateInnerDeepV2 = + IOTA_SYSTEM_STATE_SIM_TEST_DEEP_V1 => { + let result: SimTestIotaSystemStateDeepV1 = get_dynamic_field_from_store(object_store, id, &wrapper.version).map_err( |err| { IotaError::DynamicFieldRead(format!( @@ -328,7 +308,7 @@ pub fn get_iota_system_state(object_store: &dyn ObjectStore) -> Result( object_store: &dyn ObjectStore, table_id: ObjectID, @@ -337,8 +317,8 @@ pub fn get_validator_from_table( where K: MoveTypeTagTrait + Serialize + DeserializeOwned + fmt::Debug, { - let field: ValidatorWrapper = get_dynamic_field_from_store(object_store, table_id, key) - .map_err(|err| { + let field: Validator = + get_dynamic_field_from_store(object_store, table_id, key).map_err(|err| { IotaError::IotaSystemStateRead(format!( "Failed to load validator wrapper from table: {:?}", err @@ -371,7 +351,7 @@ where Ok(validator.into_iota_validator_summary()) } #[cfg(msim)] - IOTA_SYSTEM_STATE_SIM_TEST_DEEP_V2 => { + IOTA_SYSTEM_STATE_SIM_TEST_DEEP_V1 => { let validator: SimTestValidatorDeepV2 = get_dynamic_field_from_store(object_store, versioned.id.id.bytes, &version) .map_err(|err| { @@ -430,7 +410,7 @@ impl PoolTokenExchangeRate { } #[derive(Debug, Serialize, Deserialize, Clone, Eq, PartialEq)] -pub struct ValidatorWrapper { +pub struct Validator { pub inner: Versioned, } diff --git a/crates/iota-types/src/iota_system_state/simtest_iota_system_state_inner.rs b/crates/iota-types/src/iota_system_state/simtest_iota_system_state_inner.rs index d02e99e090b..fc1c17c9653 100644 --- a/crates/iota-types/src/iota_system_state/simtest_iota_system_state_inner.rs +++ b/crates/iota-types/src/iota_system_state/simtest_iota_system_state_inner.rs @@ -23,7 +23,7 @@ use crate::{ }; #[derive(Debug, Serialize, Deserialize, Clone, Eq, PartialEq)] -pub struct SimTestIotaSystemStateInnerV1 { +pub struct SimTestIotaSystemStateV1 { pub epoch: u64, pub protocol_version: u64, pub system_state_version: u64, @@ -122,7 +122,7 @@ impl VerifiedSimTestValidatorMetadataV1 { } } -impl IotaSystemStateTrait for SimTestIotaSystemStateInnerV1 { +impl IotaSystemStateTrait for SimTestIotaSystemStateV1 { fn epoch(&self) -> u64 { self.epoch } @@ -220,7 +220,7 @@ impl IotaSystemStateTrait for SimTestIotaSystemStateInnerV1 { } #[derive(Debug, Serialize, Deserialize, Clone, Eq, PartialEq)] -pub struct SimTestIotaSystemStateInnerShallowV2 { +pub struct SimTestIotaSystemStateShallowV1 { pub new_dummy_field: u64, pub epoch: u64, pub protocol_version: u64, @@ -234,7 +234,7 @@ pub struct SimTestIotaSystemStateInnerShallowV2 { pub extra_fields: Bag, } -impl IotaSystemStateTrait for SimTestIotaSystemStateInnerShallowV2 { +impl IotaSystemStateTrait for SimTestIotaSystemStateShallowV1 { fn epoch(&self) -> u64 { self.epoch } @@ -361,7 +361,7 @@ impl SimTestValidatorDeepV2 { } #[derive(Debug, Serialize, Deserialize, Clone, Eq, PartialEq)] -pub struct SimTestIotaSystemStateInnerDeepV2 { +pub struct SimTestIotaSystemStateDeepV1 { pub new_dummy_field: u64, pub epoch: u64, pub protocol_version: u64, @@ -375,7 +375,7 @@ pub struct SimTestIotaSystemStateInnerDeepV2 { pub extra_fields: Bag, } -impl IotaSystemStateTrait for SimTestIotaSystemStateInnerDeepV2 { +impl IotaSystemStateTrait for SimTestIotaSystemStateDeepV1 { fn epoch(&self) -> u64 { self.epoch } diff --git a/crates/iota-types/src/quorum_driver_types.rs b/crates/iota-types/src/quorum_driver_types.rs index 6dffb3f4ef1..8a8a0e15c15 100644 --- a/crates/iota-types/src/quorum_driver_types.rs +++ b/crates/iota-types/src/quorum_driver_types.rs @@ -148,7 +148,7 @@ impl ExecuteTransactionRequest { } #[derive(Serialize, Deserialize, Clone, Debug)] -pub struct ExecuteTransactionRequestV3 { +pub struct ExecuteTransactionRequestV1 { pub transaction: Transaction, pub include_events: bool, @@ -157,19 +157,8 @@ pub struct ExecuteTransactionRequestV3 { pub include_auxiliary_data: bool, } -#[derive(Clone, Debug)] -pub struct VerifiedExecuteTransactionResponseV3 { - pub effects: VerifiedCertifiedTransactionEffects, - pub events: Option, - // Input objects will only be populated in the happy path - pub input_objects: Option>, - // Output objects will only be populated in the happy path - pub output_objects: Option>, - pub auxiliary_data: Option>, -} - -impl ExecuteTransactionRequestV3 { - pub fn new_v2>(transaction: T) -> Self { +impl ExecuteTransactionRequestV1 { + pub fn new>(transaction: T) -> Self { Self { transaction: transaction.into(), include_events: true, @@ -181,7 +170,7 @@ impl ExecuteTransactionRequestV3 { } #[derive(Serialize, Deserialize, Clone, Debug)] -pub struct ExecuteTransactionResponseV3 { +pub struct ExecuteTransactionResponseV1 { pub effects: FinalizedEffects, pub events: Option, diff --git a/crates/iota-types/src/transaction.rs b/crates/iota-types/src/transaction.rs index 2a7d285c396..f8ff33452b3 100644 --- a/crates/iota-types/src/transaction.rs +++ b/crates/iota-types/src/transaction.rs @@ -228,7 +228,7 @@ impl AuthenticatorStateExpire { } #[derive(Debug, Hash, PartialEq, Eq, Clone, Serialize, Deserialize)] -pub struct AuthenticatorStateUpdate { +pub struct AuthenticatorStateUpdateV1 { /// Epoch of the authenticator state update transaction pub epoch: u64, /// Consensus round of the authenticator state update @@ -241,7 +241,7 @@ pub struct AuthenticatorStateUpdate { // TransactionKind. } -impl AuthenticatorStateUpdate { +impl AuthenticatorStateUpdateV1 { pub fn authenticator_obj_initial_shared_version(&self) -> SequenceNumber { self.authenticator_obj_initial_shared_version } @@ -282,7 +282,7 @@ pub enum TransactionKind { /// only signs internally during epoch changes. Genesis(GenesisTransaction), ConsensusCommitPrologueV1(ConsensusCommitPrologueV1), - AuthenticatorStateUpdate(AuthenticatorStateUpdate), + AuthenticatorStateUpdateV1(AuthenticatorStateUpdateV1), /// EndOfEpochTransaction contains a list of transactions /// that are allowed to run at the end of the epoch. @@ -1132,7 +1132,7 @@ impl TransactionKind { match self { TransactionKind::Genesis(_) | TransactionKind::ConsensusCommitPrologueV1(_) - | TransactionKind::AuthenticatorStateUpdate(_) + | TransactionKind::AuthenticatorStateUpdateV1(_) | TransactionKind::RandomnessStateUpdate(_) | TransactionKind::EndOfEpochTransaction(_) => true, TransactionKind::ProgrammableTransaction(_) => false, @@ -1178,7 +1178,7 @@ impl TransactionKind { mutable: true, }))) } - Self::AuthenticatorStateUpdate(update) => { + Self::AuthenticatorStateUpdateV1(update) => { Either::Left(Either::Left(iter::once(SharedInputObject { id: IOTA_AUTHENTICATOR_STATE_OBJECT_ID, initial_shared_version: update.authenticator_obj_initial_shared_version, @@ -1213,7 +1213,7 @@ impl TransactionKind { match &self { TransactionKind::Genesis(_) | TransactionKind::ConsensusCommitPrologueV1(_) - | TransactionKind::AuthenticatorStateUpdate(_) + | TransactionKind::AuthenticatorStateUpdateV1(_) | TransactionKind::RandomnessStateUpdate(_) | TransactionKind::EndOfEpochTransaction(_) => vec![], TransactionKind::ProgrammableTransaction(pt) => pt.receiving_objects(), @@ -1237,7 +1237,7 @@ impl TransactionKind { mutable: true, }] } - Self::AuthenticatorStateUpdate(update) => { + Self::AuthenticatorStateUpdateV1(update) => { vec![InputObjectKind::SharedMoveObject { id: IOTA_AUTHENTICATOR_STATE_OBJECT_ID, initial_shared_version: update.authenticator_obj_initial_shared_version(), @@ -1293,7 +1293,7 @@ impl TransactionKind { } } - TransactionKind::AuthenticatorStateUpdate(_) => { + TransactionKind::AuthenticatorStateUpdateV1(_) => { if !config.enable_jwk_consensus_updates() { return Err(UserInputError::Unsupported( "authenticator state updates not enabled".to_string(), @@ -1333,7 +1333,7 @@ impl TransactionKind { Self::Genesis(_) => "Genesis", Self::ConsensusCommitPrologueV1(_) => "ConsensusCommitPrologueV1", Self::ProgrammableTransaction(_) => "ProgrammableTransaction", - Self::AuthenticatorStateUpdate(_) => "AuthenticatorStateUpdate", + Self::AuthenticatorStateUpdateV1(_) => "AuthenticatorStateUpdateV1", Self::RandomnessStateUpdate(_) => "RandomnessStateUpdate", Self::EndOfEpochTransaction(_) => "EndOfEpochTransaction", } @@ -1361,7 +1361,7 @@ impl Display for TransactionKind { writeln!(writer, "Transaction Kind : Programmable")?; write!(writer, "{p}")?; } - Self::AuthenticatorStateUpdate(_) => { + Self::AuthenticatorStateUpdateV1(_) => { writeln!(writer, "Transaction Kind : Authenticator State Update")?; } Self::RandomnessStateUpdate(_) => { @@ -2395,13 +2395,13 @@ impl VerifiedTransaction { new_active_jwks: Vec, authenticator_obj_initial_shared_version: SequenceNumber, ) -> Self { - AuthenticatorStateUpdate { + AuthenticatorStateUpdateV1 { epoch, round, new_active_jwks, authenticator_obj_initial_shared_version, } - .pipe(TransactionKind::AuthenticatorStateUpdate) + .pipe(TransactionKind::AuthenticatorStateUpdateV1) .pipe(Self::new_system_transaction) } diff --git a/crates/iota-types/src/transaction_executor.rs b/crates/iota-types/src/transaction_executor.rs index e2c5cd8a32c..b349ca96810 100644 --- a/crates/iota-types/src/transaction_executor.rs +++ b/crates/iota-types/src/transaction_executor.rs @@ -3,7 +3,7 @@ // SPDX-License-Identifier: Apache-2.0 use crate::quorum_driver_types::{ - ExecuteTransactionRequestV3, ExecuteTransactionResponseV3, QuorumDriverError, + ExecuteTransactionRequestV1, ExecuteTransactionResponseV1, QuorumDriverError, }; /// Trait to define the interface for how the REST service interacts with a a @@ -12,7 +12,7 @@ use crate::quorum_driver_types::{ pub trait TransactionExecutor: Send + Sync { async fn execute_transaction( &self, - request: ExecuteTransactionRequestV3, + request: ExecuteTransactionRequestV1, client_addr: Option, - ) -> Result; + ) -> Result; } diff --git a/crates/iota/src/validator_commands.rs b/crates/iota/src/validator_commands.rs index f9565c555af..5b14959c2d8 100644 --- a/crates/iota/src/validator_commands.rs +++ b/crates/iota/src/validator_commands.rs @@ -44,7 +44,7 @@ use iota_types::{ generate_proof_of_possession, get_authority_key_pair, }, iota_system_state::{ - iota_system_state_inner_v1::{UnverifiedValidatorOperationCapV1, ValidatorV1}, + iota_system_state_inner_v1::{UnverifiedValidatorOperationCap, ValidatorV1}, iota_system_state_summary::{IotaSystemStateSummary, IotaValidatorSummary}, }, multiaddr::Multiaddr, @@ -865,7 +865,7 @@ async fn get_validator_summary_from_cap_id( operation_cap_id ) })?; - let cap = bcs::from_bytes::(bcs).map_err(|e| { + let cap = bcs::from_bytes::(bcs).map_err(|e| { anyhow::anyhow!( "Can't convert bcs bytes of object {} to UnverifiedValidatorOperationCapV1: {}", operation_cap_id, diff --git a/crates/test-cluster/src/lib.rs b/crates/test-cluster/src/lib.rs index 8249c4fcfc2..f65967780ae 100644 --- a/crates/test-cluster/src/lib.rs +++ b/crates/test-cluster/src/lib.rs @@ -56,7 +56,7 @@ use iota_swarm_config::{ genesis_config::{AccountConfig, DEFAULT_GAS_AMOUNT, GenesisConfig, ValidatorGenesisConfig}, network_config::{NetworkConfig, NetworkConfigLight}, network_config_builder::{ - ProtocolVersionsConfig, StateAccumulatorV2EnabledCallback, StateAccumulatorV2EnabledConfig, + ProtocolVersionsConfig, StateAccumulatorEnabledCallback, StateAccumulatorV1EnabledConfig, SupportedProtocolVersionsCallback, }, node_config_builder::{FullnodeConfigBuilder, ValidatorConfigBuilder}, @@ -612,7 +612,7 @@ impl TestCluster { .unwrap(); match &tx.data().intent_message().value.kind() { TransactionKind::EndOfEpochTransaction(_) => (), - TransactionKind::AuthenticatorStateUpdate(_) => break, + TransactionKind::AuthenticatorStateUpdateV1(_) => break, _ => panic!("{:?}", tx), } } @@ -1039,7 +1039,7 @@ pub struct TestClusterBuilder { max_submit_position: Option, submit_delay_step_override_millis: Option, - validator_state_accumulator_v2_enabled_config: StateAccumulatorV2EnabledConfig, + validator_state_accumulator_config: StateAccumulatorV1EnabledConfig, } impl TestClusterBuilder { @@ -1067,9 +1067,7 @@ impl TestClusterBuilder { fullnode_fw_config: None, max_submit_position: None, submit_delay_step_override_millis: None, - validator_state_accumulator_v2_enabled_config: StateAccumulatorV2EnabledConfig::Global( - true, - ), + validator_state_accumulator_config: StateAccumulatorV1EnabledConfig::Global(true), } } @@ -1190,12 +1188,12 @@ impl TestClusterBuilder { self } - pub fn with_state_accumulator_v2_enabled_callback( + pub fn with_state_accumulator_callback( mut self, - func: StateAccumulatorV2EnabledCallback, + func: StateAccumulatorEnabledCallback, ) -> Self { - self.validator_state_accumulator_v2_enabled_config = - StateAccumulatorV2EnabledConfig::PerValidator(func); + self.validator_state_accumulator_config = + StateAccumulatorV1EnabledConfig::PerValidator(func); self } @@ -1519,9 +1517,7 @@ impl TestClusterBuilder { .with_supported_protocol_versions_config( self.validator_supported_protocol_versions_config.clone(), ) - .with_state_accumulator_v2_enabled_config( - self.validator_state_accumulator_v2_enabled_config.clone(), - ) + .with_state_accumulator_config(self.validator_state_accumulator_config.clone()) .with_fullnode_count(1) .with_fullnode_supported_protocol_versions_config( self.fullnode_supported_protocol_versions_config diff --git a/iota-execution/latest/iota-adapter/src/execution_engine.rs b/iota-execution/latest/iota-adapter/src/execution_engine.rs index 2493cc97387..e40a42debb1 100644 --- a/iota-execution/latest/iota-adapter/src/execution_engine.rs +++ b/iota-execution/latest/iota-adapter/src/execution_engine.rs @@ -55,7 +55,7 @@ mod checked { randomness_state::{RANDOMNESS_MODULE_NAME, RANDOMNESS_STATE_UPDATE_FUNCTION_NAME}, storage::{BackingStore, Storage}, transaction::{ - Argument, AuthenticatorStateExpire, AuthenticatorStateUpdate, CallArg, ChangeEpoch, + Argument, AuthenticatorStateExpire, AuthenticatorStateUpdateV1, CallArg, ChangeEpoch, CheckedInputObjects, Command, EndOfEpochTransactionKind, GenesisTransaction, ObjectArg, ProgrammableTransaction, RandomnessStateUpdate, TransactionKind, }, @@ -702,7 +702,7 @@ mod checked { "EndOfEpochTransactionKind::ChangeEpoch should be the last transaction in the list" ) } - TransactionKind::AuthenticatorStateUpdate(auth_state_update) => { + TransactionKind::AuthenticatorStateUpdateV1(auth_state_update) => { setup_authenticator_state_update( auth_state_update, temporary_store, @@ -1117,7 +1117,7 @@ mod checked { /// arguments. It then executes the transaction using the system /// execution mode. fn setup_authenticator_state_update( - update: AuthenticatorStateUpdate, + update: AuthenticatorStateUpdateV1, temporary_store: &mut TemporaryStore<'_>, tx_ctx: &mut TxContext, move_vm: &Arc, diff --git a/iota-execution/v0/iota-adapter/src/execution_engine.rs b/iota-execution/v0/iota-adapter/src/execution_engine.rs index 755dc13140f..bfbc94ffc70 100644 --- a/iota-execution/v0/iota-adapter/src/execution_engine.rs +++ b/iota-execution/v0/iota-adapter/src/execution_engine.rs @@ -55,7 +55,7 @@ mod checked { randomness_state::{RANDOMNESS_MODULE_NAME, RANDOMNESS_STATE_UPDATE_FUNCTION_NAME}, storage::{BackingStore, Storage}, transaction::{ - Argument, AuthenticatorStateExpire, AuthenticatorStateUpdate, CallArg, ChangeEpoch, + Argument, AuthenticatorStateExpire, AuthenticatorStateUpdateV1, CallArg, ChangeEpoch, CheckedInputObjects, Command, EndOfEpochTransactionKind, GenesisTransaction, ObjectArg, ProgrammableTransaction, RandomnessStateUpdate, TransactionKind, }, @@ -655,7 +655,7 @@ mod checked { "EndOfEpochTransactionKind::ChangeEpoch should be the last transaction in the list" ) } - TransactionKind::AuthenticatorStateUpdate(auth_state_update) => { + TransactionKind::AuthenticatorStateUpdateV1(auth_state_update) => { setup_authenticator_state_update( auth_state_update, temporary_store, @@ -1036,7 +1036,7 @@ mod checked { } fn setup_authenticator_state_update( - update: AuthenticatorStateUpdate, + update: AuthenticatorStateUpdateV1, temporary_store: &mut TemporaryStore<'_>, tx_ctx: &mut TxContext, move_vm: &Arc, diff --git a/narwhal/types/src/primary.rs b/narwhal/types/src/primary.rs index 650d8e0f41c..d5ebd4cf080 100644 --- a/narwhal/types/src/primary.rs +++ b/narwhal/types/src/primary.rs @@ -152,17 +152,17 @@ impl MetadataAPI for MetadataV1 { #[derive(Clone, Serialize, Deserialize, Debug, PartialEq, Eq, Arbitrary)] #[enum_dispatch(BatchAPI)] pub enum Batch { - V2(BatchV2), + V1(BatchV1), } impl Batch { pub fn new(transactions: Vec) -> Self { - Self::V2(BatchV2::new(transactions)) + Self::V1(BatchV1::new(transactions)) } pub fn size(&self) -> usize { match self { - Batch::V2(data) => data.size(), + Batch::V1(data) => data.size(), } } } @@ -172,7 +172,7 @@ impl Hash<{ crypto::DIGEST_LENGTH }> for Batch { fn digest(&self) -> BatchDigest { match self { - Batch::V2(data) => data.digest(), + Batch::V1(data) => data.digest(), } } } @@ -183,7 +183,6 @@ pub trait BatchAPI { fn transactions_mut(&mut self) -> &mut Vec; fn into_transactions(self) -> Vec; - // BatchV2 APIs fn versioned_metadata(&self) -> &VersionedMetadata; fn versioned_metadata_mut(&mut self) -> &mut VersionedMetadata; } @@ -191,13 +190,13 @@ pub trait BatchAPI { pub type Transaction = Vec; #[derive(Clone, Serialize, Deserialize, Debug, PartialEq, Eq, Arbitrary)] -pub struct BatchV2 { +pub struct BatchV1 { pub transactions: Vec, // This field is not included as part of the batch digest pub versioned_metadata: VersionedMetadata, } -impl BatchAPI for BatchV2 { +impl BatchAPI for BatchV1 { fn transactions(&self) -> &Vec { &self.transactions } @@ -219,7 +218,7 @@ impl BatchAPI for BatchV2 { } } -impl BatchV2 { +impl BatchV1 { pub fn new(transactions: Vec) -> Self { Self { transactions, @@ -288,7 +287,7 @@ impl BatchDigest { } } -impl Hash<{ crypto::DIGEST_LENGTH }> for BatchV2 { +impl Hash<{ crypto::DIGEST_LENGTH }> for BatchV1 { type TypedDigest = BatchDigest; fn digest(&self) -> Self::TypedDigest { @@ -789,14 +788,14 @@ impl PartialEq for Vote { #[derive(Clone, Serialize, Deserialize, MallocSizeOf)] #[enum_dispatch(CertificateAPI)] pub enum Certificate { - V2(CertificateV2), + V1(CertificateV1), } impl Certificate { pub fn genesis(committee: &Committee) -> Vec { - CertificateV2::genesis(committee) + CertificateV1::genesis(committee) .into_iter() - .map(Self::V2) + .map(Self::V1) .collect() } @@ -805,7 +804,7 @@ impl Certificate { header: Header, votes: Vec<(AuthorityIdentifier, Signature)>, ) -> DagResult { - CertificateV2::new_unverified(committee, header, votes) + CertificateV1::new_unverified(committee, header, votes) } pub fn new_unsigned( @@ -813,20 +812,20 @@ impl Certificate { header: Header, votes: Vec<(AuthorityIdentifier, Signature)>, ) -> DagResult { - CertificateV2::new_unsigned(committee, header, votes) + CertificateV1::new_unsigned(committee, header, votes) } /// This function requires that certificate was verified against given /// committee pub fn signed_authorities(&self, committee: &Committee) -> Vec { match self { - Self::V2(certificate) => certificate.signed_authorities(committee), + Self::V1(certificate) => certificate.signed_authorities(committee), } } pub fn signed_by(&self, committee: &Committee) -> (Stake, Vec) { match self { - Self::V2(certificate) => certificate.signed_by(committee), + Self::V1(certificate) => certificate.signed_by(committee), } } @@ -836,30 +835,30 @@ impl Certificate { worker_cache: &WorkerCache, ) -> DagResult { match self { - Self::V2(certificate) => certificate.verify(committee, worker_cache), + Self::V1(certificate) => certificate.verify(committee, worker_cache), } } pub fn round(&self) -> Round { match self { - Self::V2(certificate) => certificate.round(), + Self::V1(certificate) => certificate.round(), } } pub fn epoch(&self) -> Epoch { match self { - Self::V2(certificate) => certificate.epoch(), + Self::V1(certificate) => certificate.epoch(), } } pub fn origin(&self) -> AuthorityIdentifier { match self { - Self::V2(certificate) => certificate.origin(), + Self::V1(certificate) => certificate.origin(), } } pub fn default_for_testing() -> Certificate { - Certificate::V2(CertificateV2::default()) + Certificate::V1(CertificateV1::default()) } } @@ -868,7 +867,7 @@ impl Hash<{ crypto::DIGEST_LENGTH }> for Certificate { fn digest(&self) -> CertificateDigest { match self { - Certificate::V2(data) => data.digest(), + Certificate::V1(data) => data.digest(), } } } @@ -884,7 +883,7 @@ pub trait CertificateAPI { fn update_header(&mut self, header: Header); fn header_mut(&mut self) -> &mut Header; - // CertificateV2 + // CertificateV1 fn signature_verification_state(&self) -> &SignatureVerificationState; fn set_signature_verification_state(&mut self, state: SignatureVerificationState); } @@ -922,7 +921,7 @@ impl Default for SignatureVerificationState { #[serde_as] #[derive(Clone, Serialize, Deserialize, Default, MallocSizeOf)] -pub struct CertificateV2 { +pub struct CertificateV1 { pub header: Header, pub signature_verification_state: SignatureVerificationState, #[serde_as(as = "NarwhalBitmap")] @@ -930,7 +929,7 @@ pub struct CertificateV2 { pub metadata: Metadata, } -impl CertificateAPI for CertificateV2 { +impl CertificateAPI for CertificateV1 { fn header(&self) -> &Header { &self.header } @@ -971,7 +970,7 @@ impl CertificateAPI for CertificateV2 { } } -impl CertificateV2 { +impl CertificateV1 { pub fn genesis(committee: &Committee) -> Vec { committee .authorities() @@ -1065,7 +1064,7 @@ impl CertificateV2 { SignatureVerificationState::Unverified(aggregate_signature_bytes) }; - Ok(Certificate::V2(CertificateV2 { + Ok(Certificate::V1(CertificateV1 { header, signature_verification_state, signed_authorities, @@ -1117,7 +1116,7 @@ impl CertificateV2 { // Genesis certificates are always valid. if self.round() == 0 && Self::genesis(committee).contains(&self) { - return Ok(Certificate::V2(self)); + return Ok(Certificate::V1(self)); } // Save signature verifications when the header is invalid. @@ -1139,7 +1138,7 @@ impl CertificateV2 { let aggregate_signature_bytes = match self.signature_verification_state { SignatureVerificationState::VerifiedIndirectly(_) | SignatureVerificationState::VerifiedDirectly(_) - | SignatureVerificationState::Genesis => return Ok(Certificate::V2(self)), + | SignatureVerificationState::Genesis => return Ok(Certificate::V1(self)), SignatureVerificationState::Unverified(ref bytes) => bytes, SignatureVerificationState::Unsigned(_) => { bail!(DagError::CertificateRequiresQuorum); @@ -1156,7 +1155,7 @@ impl CertificateV2 { self.signature_verification_state = SignatureVerificationState::VerifiedDirectly(aggregate_signature_bytes.clone()); - Ok(Certificate::V2(self)) + Ok(Certificate::V1(self)) } pub fn round(&self) -> Round { @@ -1173,15 +1172,15 @@ impl CertificateV2 { } // Certificate version is validated against network protocol version. If -// CertificateV2 is being used then the cert will also be marked as Unverified +// CertificateV1 is being used then the cert will also be marked as Unverified // as this certificate is assumed to be received from the network. This // SignatureVerificationState is why the modified certificate is being returned. pub fn validate_received_certificate_version( mut certificate: Certificate, ) -> anyhow::Result { match certificate { - Certificate::V2(_) => { - // CertificateV2 was received from the network so we need to mark + Certificate::V1(_) => { + // CertificateV1 was received from the network so we need to mark // certificate aggregated signature state as unverified. certificate.set_signature_verification_state(SignatureVerificationState::Unverified( certificate @@ -1251,7 +1250,7 @@ impl fmt::Display for CertificateDigest { } } -impl Hash<{ crypto::DIGEST_LENGTH }> for CertificateV2 { +impl Hash<{ crypto::DIGEST_LENGTH }> for CertificateV1 { type TypedDigest = CertificateDigest; fn digest(&self) -> CertificateDigest { @@ -1262,7 +1261,7 @@ impl Hash<{ crypto::DIGEST_LENGTH }> for CertificateV2 { impl fmt::Debug for Certificate { fn fmt(&self, f: &mut fmt::Formatter<'_>) -> Result<(), fmt::Error> { match self { - Certificate::V2(data) => write!( + Certificate::V1(data) => write!( f, "{}: C{}({}, {}, E{})", data.digest(), @@ -1278,12 +1277,12 @@ impl fmt::Debug for Certificate { impl PartialEq for Certificate { fn eq(&self, other: &Self) -> bool { match (self, other) { - (Certificate::V2(data), Certificate::V2(other_data)) => data.eq(other_data), + (Certificate::V1(data), Certificate::V1(other_data)) => data.eq(other_data), } } } -impl PartialEq for CertificateV2 { +impl PartialEq for CertificateV1 { fn eq(&self, other: &Self) -> bool { let mut ret = self.header().digest() == other.header().digest(); ret &= self.round() == other.round(); @@ -1513,7 +1512,7 @@ mod tests { use tokio::time::sleep; - use crate::{Batch, BatchAPI, BatchV2, MetadataAPI, MetadataV1, Timestamp, VersionedMetadata}; + use crate::{Batch, BatchAPI, BatchV1, MetadataAPI, MetadataV1, Timestamp, VersionedMetadata}; #[tokio::test] async fn test_elapsed() { @@ -1537,7 +1536,7 @@ mod tests { #[test] fn test_elapsed_when_newer_than_now() { - let batch = Batch::V2(BatchV2 { + let batch = Batch::V1(BatchV1 { transactions: vec![], versioned_metadata: VersionedMetadata::V1(MetadataV1 { created_at: 2999309726980, // something in the future - Fri Jan 16 2065 05:35:26 diff --git a/narwhal/types/src/tests/batch_serde.rs b/narwhal/types/src/tests/batch_serde.rs index 7e8fb69a2cc..3529421ae9f 100644 --- a/narwhal/types/src/tests/batch_serde.rs +++ b/narwhal/types/src/tests/batch_serde.rs @@ -5,13 +5,13 @@ use serde_test::{Token, assert_tokens}; use crate::{ - Batch, BatchV2, MetadataV1, VersionedMetadata, serde::batch_serde::Token::NewtypeVariant, + Batch, BatchV1, MetadataV1, VersionedMetadata, serde::batch_serde::Token::NewtypeVariant, }; #[test] fn test_serde_batch() { let tx = || vec![1; 5]; - let batch = Batch::V2(BatchV2 { + let batch = Batch::V1(BatchV1 { transactions: (0..2).map(|_| tx()).collect(), versioned_metadata: VersionedMetadata::V1(MetadataV1 { created_at: 1666205365890, @@ -22,10 +22,10 @@ fn test_serde_batch() { assert_tokens(&batch, &[ NewtypeVariant { name: "Batch", - variant: "V2", + variant: "V1", }, Token::Struct { - name: "BatchV2", + name: "BatchV1", len: 2, }, Token::Str("transactions"),